Uploaded image for project: 'Apache Trafodion (Retired)'
  1. Apache Trafodion (Retired)
  2. TRAFODION-3107

selct count(0) with long varchar hitting jvm OOM error

    XMLWordPrintableJSON

Details

    • Bug
    • Status: Closed
    • Major
    • Resolution: Fixed
    • None
    • 2.3
    • None
    • None

    Description

      selct count(0) hitting jvm OOM error when clob as varchar and insert some 5MB images.

      org.trafodion.jdbc.t4.TrafT4Exception: *** ERROR[8448] Unable to access Hbase interface. Call to ExpHbaseInterface::nextRow returned error HBASE_ACCESS_ERROR(-706). Cause: java.util.concurrent.ExecutionException: org.apache.hadoop.hbase.client.RetriesExhaustedException: Failed after attempts=3, exceptions:
      Tue Jun 05 10:53:33 CST 2018, RpcRetryingCaller{globalStartTime=1528167213257, pause=100, retries=3}, java.lang.RuntimeException: java.lang.OutOfMemoryError: Java heap space
      Tue Jun 05 10:53:34 CST 2018, RpcRetryingCaller{globalStartTime=1528167213257, pause=100, retries=3}, java.lang.RuntimeException: java.lang.OutOfMemoryError: Java heap space
      Tue Jun 05 10:53:34 CST 2018, RpcRetryingCaller{globalStartTime=1528167213257, pause=100, retries=3}, java.lang.RuntimeException: java.lang.OutOfMemoryError: Java heap space
       
      java.util.concurrent.FutureTask.report(FutureTask.java:122)
      java.util.concurrent.FutureTask.get(FutureTask.java:192)
      org.trafodion.sql.HTableClient.fetchRows(HTableClient.java:1287) Caused by 
      org.apache.hadoop.hbase.client.RetriesExhaustedException: Failed after attempts=3, exceptions:
      Tue Jun 05 10:53:33 CST 2018, RpcRetryingCaller{globalStartTime=1528167213257, pause=100, retries=3}, java.lang.RuntimeException: java.lang.OutOfMemoryError: Java heap space
      Tue Jun 05 10:53:34 CST 2018, RpcRetryingCaller{globalStartTime=1528167213257, pause=100, retries=3}, java.lang.RuntimeException: java.lang.OutOfMemoryError: Java heap space
      Tue Jun 05 10:53:34 CST 2018, RpcRetryingCaller{globalStartTime=1528167213257, pause=100, retries=3}, java.lang.RuntimeException: java.lang.OutOfMemoryError: Java heap space
       
      org.apache.hadoop.hbase.client.RpcRetryingCaller.callWithRetries(RpcRetryingCaller.java:157)
      org.apache.hadoop.hbase.client.ResultBoundedCompletionService$QueueingFuture.run(ResultBoundedCompletionService.java:80)
      java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1142)
      java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:617)
      java.lang.Thread.run(Thread.java:745) Caused by 
      java.lang.RuntimeException: java.lang.OutOfMemoryError: Java heap space
      org.apache.hadoop.hbase.client.RpcRetryingCaller.callWithoutRetries(RpcRetryingCaller.java:218)
      org.apache.hadoop.hbase.client.ScannerCallableWithReplicas$RetryingRPC.call(ScannerCallableWithReplicas.java:397)
      org.apache.hadoop.hbase.client.ScannerCallableWithReplicas$RetryingRPC.call(ScannerCallableWithReplicas.java:371)
      org.apache.hadoop.hbase.client.RpcRetryingCaller.callWithRetries(RpcRetryingCaller.java:136)
      org.apache.hadoop.hbase.client.ResultBoundedCompletionService$QueueingFuture.run(ResultBoundedCompletionService.java:80)
      java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1142)
      java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:617)
      java.lang.Thread.run(Thread.java:745) Caused by 
      java.lang.OutOfMemoryError: Java heap space. [2018-06-05 10:53:34]
         at org.trafodion.jdbc.t4.TrafT4Messages.throwSQLException(TrafT4Messages.java:211)
         at org.trafodion.jdbc.t4.InterfaceResultSet.fetch(InterfaceResultSet.java:857)
         at org.trafodion.jdbc.t4.TrafT4ResultSet.next(TrafT4ResultSet.java:2786)
         at org.jdbctest.performance.lob.LobPerformance.test_clob_photo_normal(LobPerformance.java:1469)
         at org.jdbctest.performance.lob.LobPerformance.test_jdbc_api(LobPerformance.java:374)
         at org.jdbctest.performance.lob.LobPerformance.main(LobPerformance.java:319)

      Attachments

        Issue Links

          Activity

            People

              sandhya Sandhya Sundaresan
              sandhya Sandhya Sundaresan
              Votes:
              0 Vote for this issue
              Watchers:
              2 Start watching this issue

              Dates

                Created:
                Updated:
                Resolved: