You are viewing a plain text version of this content. The canonical link for it is here.
Posted to dev@drill.apache.org by "Chun Chang (JIRA)" <ji...@apache.org> on 2014/04/09 22:49:18 UTC

[jira] [Created] (DRILL-496) drill stuck in loop when query parquet file and eventually ran out of memory

Chun Chang created DRILL-496:
--------------------------------

             Summary: drill stuck in loop when query parquet file and eventually ran out of memory
                 Key: DRILL-496
                 URL: https://issues.apache.org/jira/browse/DRILL-496
             Project: Apache Drill
          Issue Type: Bug
    Affects Versions: 1.0.0-milestone-2
            Reporter: Chun Chang
            Priority: Blocker


Ran the following Mondrian query against parquet format file and hit the issue that drill bit in infinite loop, and eventually run out of memory.

0: jdbc:drill:schema=dfs> select * from days;

drillbit log:

Exception in thread "WorkManager-3" java.lang.OutOfMemoryError: Direct buffer memory
        at java.nio.Bits.reserveMemory(Bits.java:658)
        at java.nio.DirectByteBuffer.<init>(DirectByteBuffer.java:123)
        at java.nio.ByteBuffer.allocateDirect(ByteBuffer.java:306)
        at io.netty.buffer.PoolArenaL$DirectArena.newUnpooledChunk(PoolArenaL.java:387)
        at io.netty.buffer.PoolArenaL.allocateHuge(PoolArenaL.java:152)
        at io.netty.buffer.PoolArenaL.allocate(PoolArenaL.java:129)
        at io.netty.buffer.PoolArenaL.reallocate(PoolArenaL.java:234)
        at io.netty.buffer.PooledByteBufL.capacity(PooledByteBufL.java:116)
        at io.netty.buffer.AbstractByteBuf.ensureWritable(AbstractByteBuf.java:250)
        at io.netty.buffer.AbstractByteBuf.writeBytes(AbstractByteBuf.java:807)
        at org.apache.drill.exec.memory.AccountingByteBuf.writeBytes(AccountingByteBuf.java:664)
        at org.apache.drill.exec.store.parquet.NullableFixedByteAlignedReader.readField(NullableFixedByteAlignedReader.java:48)
        at org.apache.drill.exec.store.parquet.NullableColumnReader.readAllFixedFields(NullableColumnReader.java:106)
        at org.apache.drill.exec.store.parquet.ParquetRecordReader.readAllFixedFields(ParquetRecordReader.java:327)
        at org.apache.drill.exec.store.parquet.ParquetRecordReader.next(ParquetRecordReader.java:369)
        at org.apache.drill.exec.physical.impl.ScanBatch.next(ScanBatch.java:94)
        at org.apache.drill.exec.record.AbstractSingleRecordBatch.next(AbstractSingleRecordBatch.java:42)
        at org.apache.drill.exec.physical.impl.ScreenCreator$ScreenRoot.next(ScreenCreator.java:85)
        at org.apache.drill.exec.work.fragment.FragmentExecutor.run(FragmentExecutor.java:83)
        at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1145)
        at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:615)
        at java.lang.Thread.run(Thread.java:744)






--
This message was sent by Atlassian JIRA
(v6.2#6252)