Uses of Class
org.apache.drill.exec.exception.OutOfMemoryException
Package
Description
Java client API for submitting queries and accepting result sets from a Drill
server.
Memory Allocation, Account and Management
See the README.md file in this directory for detailed information about Drill's memory allocation subsystem.
Drill storage plugin.
Defines a mock data source which generates dummy test data for use
in testing.
-
Uses of OutOfMemoryException in org.apache.drill.exec.client
ModifierConstructorDescriptionDrillClient
(boolean isDirect) DrillClient
(String fileName) DrillClient
(DrillConfig config) DrillClient
(DrillConfig config, boolean isDirect) DrillClient
(DrillConfig config, ClusterCoordinator coordinator) DrillClient
(DrillConfig config, ClusterCoordinator coordinator, boolean isDirect) DrillClient
(DrillConfig config, ClusterCoordinator coordinator, BufferAllocator allocator) -
Uses of OutOfMemoryException in org.apache.drill.exec.memory
ModifierConstructorDescriptionprotected
BaseAllocator
(BaseAllocator parentAllocator, String name, long initReservation, long maxAllocation) -
Uses of OutOfMemoryException in org.apache.drill.exec.ops
Modifier and TypeMethodDescriptionFragmentContextImpl.getNewChildAllocator
(String operatorName, int operatorId, long initialReservation, long maximumReservation) FragmentContextImpl.newOperatorContext
(PhysicalOperator popConfig) FragmentContextImpl.newOperatorContext
(PhysicalOperator popConfig, OperatorStats stats) FragmentContextInterface.newOperatorContext
(PhysicalOperator popConfig) FragmentContextInterface.newOperatorContext
(PhysicalOperator popConfig, OperatorStats stats) -
Uses of OutOfMemoryException in org.apache.drill.exec.physical.impl
Modifier and TypeMethodDescriptionMergingReceiverCreator.getBatch
(ExecutorFragmentContext context, MergingReceiverPOP receiver, List<RecordBatch> children) ModifierConstructorDescriptionBaseRootExec
(RootFragmentContext fragmentContext, OperatorContext oContext, PhysicalOperator config) BaseRootExec
(RootFragmentContext fragmentContext, PhysicalOperator config) InsertWriterRecordBatch
(Writer writer, RecordBatch incoming, FragmentContext context, RecordWriter recordWriter) SingleSenderRootExec
(RootFragmentContext context, RecordBatch batch, SingleSender config) StatisticsWriterRecordBatch
(Writer writer, RecordBatch incoming, FragmentContext context, StatisticsRecordWriter recordWriter) WriterRecordBatch
(Writer writer, RecordBatch incoming, FragmentContext context, RecordWriter recordWriter) -
Uses of OutOfMemoryException in org.apache.drill.exec.physical.impl.aggregate
ModifierConstructorDescriptionStreamingAggBatch
(StreamingAggregate popConfig, RecordBatch incoming, FragmentContext context) -
Uses of OutOfMemoryException in org.apache.drill.exec.physical.impl.broadcastsender
ModifierConstructorDescriptionBroadcastSenderRootExec
(RootFragmentContext context, RecordBatch incoming, BroadcastSender config) -
Uses of OutOfMemoryException in org.apache.drill.exec.physical.impl.filter
ModifierConstructorDescriptionFilterRecordBatch
(Filter pop, RecordBatch incoming, FragmentContext context) RuntimeFilterRecordBatch
(RuntimeFilterPOP pop, RecordBatch incoming, FragmentContext context) -
Uses of OutOfMemoryException in org.apache.drill.exec.physical.impl.flatten
ModifierConstructorDescriptionFlattenRecordBatch
(FlattenPOP pop, RecordBatch incoming, FragmentContext context) -
Uses of OutOfMemoryException in org.apache.drill.exec.physical.impl.join
ModifierConstructorDescriptionAbstractHashBinaryRecordBatch
(T popConfig, FragmentContext context, RecordBatch left, RecordBatch right) The constructorHashJoinBatch
(HashJoinPOP popConfig, FragmentContext context, RecordBatch left, RecordBatch right) The constructorLateralJoinBatch
(LateralJoinPOP popConfig, FragmentContext context, RecordBatch left, RecordBatch right) protected
MergeJoinBatch
(MergeJoinPOP popConfig, FragmentContext context, RecordBatch left, RecordBatch right) protected
NestedLoopJoinBatch
(NestedLoopJoinPOP popConfig, FragmentContext context, RecordBatch left, RecordBatch right) RowKeyJoinBatch
(RowKeyJoinPOP config, FragmentContext context, RecordBatch left, RecordBatch right) -
Uses of OutOfMemoryException in org.apache.drill.exec.physical.impl.limit
ModifierConstructorDescriptionLimitRecordBatch
(Limit popConfig, FragmentContext context, RecordBatch incoming) PartitionLimitRecordBatch
(PartitionLimit popConfig, FragmentContext context, RecordBatch incoming) -
Uses of OutOfMemoryException in org.apache.drill.exec.physical.impl.mergereceiver
ModifierConstructorDescriptionMergingRecordBatch
(ExchangeFragmentContext context, MergingReceiverPOP config, RawFragmentBatchProvider[] fragProviders) -
Uses of OutOfMemoryException in org.apache.drill.exec.physical.impl.metadata
ModifierConstructorDescriptionprotected
MetadataControllerBatch
(MetadataControllerPOP popConfig, FragmentContext context, RecordBatch left, RecordBatch right) protected
MetadataHandlerBatch
(MetadataHandlerPOP popConfig, FragmentContext context, RecordBatch incoming) MetadataStreamAggBatch
(MetadataStreamAggPOP popConfig, RecordBatch incoming, FragmentContext context) -
Uses of OutOfMemoryException in org.apache.drill.exec.physical.impl.orderedpartitioner
ModifierConstructorDescriptionOrderedPartitionRecordBatch
(OrderedPartitionSender pop, RecordBatch incoming, FragmentContext context) -
Uses of OutOfMemoryException in org.apache.drill.exec.physical.impl.partitionsender
ModifierConstructorDescriptionPartitionSenderRootExec
(RootFragmentContext context, RecordBatch incoming, HashPartitionSender operator) PartitionSenderRootExec
(RootFragmentContext context, RecordBatch incoming, HashPartitionSender operator, boolean closeIncoming) -
Uses of OutOfMemoryException in org.apache.drill.exec.physical.impl.producer
ModifierConstructorDescriptionprotected
ProducerConsumerBatch
(ProducerConsumer popConfig, FragmentContext context, RecordBatch incoming) -
Uses of OutOfMemoryException in org.apache.drill.exec.physical.impl.rangepartitioner
ModifierConstructorDescriptionRangePartitionRecordBatch
(RangePartitionSender popConfig, RecordBatch incoming, FragmentContext context) -
Uses of OutOfMemoryException in org.apache.drill.exec.physical.impl.setop
ModifierConstructorDescriptionHashSetOpRecordBatch
(SetOp popConfig, FragmentContext context, RecordBatch left, RecordBatch right) The constructor -
Uses of OutOfMemoryException in org.apache.drill.exec.physical.impl.sort
ModifierConstructorDescriptionSortBatch
(Sort popConfig, FragmentContext context, RecordBatch incoming) -
Uses of OutOfMemoryException in org.apache.drill.exec.physical.impl.statistics
ModifierConstructorDescriptionStatisticsAggBatch
(StatisticsAggregate popConfig, RecordBatch incoming, FragmentContext context) StatisticsMergeBatch
(StatisticsMerge popConfig, RecordBatch incoming, FragmentContext context) -
Uses of OutOfMemoryException in org.apache.drill.exec.physical.impl.svremover
ModifierConstructorDescriptionRemovingRecordBatch
(SelectionVectorRemover popConfig, FragmentContext context, RecordBatch incoming) -
Uses of OutOfMemoryException in org.apache.drill.exec.physical.impl.TopN
ModifierConstructorDescriptionTopNBatch
(TopN popConfig, FragmentContext context, RecordBatch incoming) -
Uses of OutOfMemoryException in org.apache.drill.exec.physical.impl.union
ModifierConstructorDescriptionUnionAllRecordBatch
(UnionAll config, List<RecordBatch> children, FragmentContext context) -
Uses of OutOfMemoryException in org.apache.drill.exec.physical.impl.unnest
-
Uses of OutOfMemoryException in org.apache.drill.exec.physical.impl.unorderedreceiver
ModifierConstructorDescriptionUnorderedReceiverBatch
(ExchangeFragmentContext context, RawFragmentBatchProvider fragProvider, UnorderedReceiver config) -
Uses of OutOfMemoryException in org.apache.drill.exec.physical.impl.unpivot
ModifierConstructorDescriptionUnpivotMapsRecordBatch
(UnpivotMaps pop, RecordBatch incoming, FragmentContext context) -
Uses of OutOfMemoryException in org.apache.drill.exec.physical.impl.window
ModifierConstructorDescriptionWindowFrameRecordBatch
(WindowPOP popConfig, FragmentContext context, RecordBatch incoming) -
Uses of OutOfMemoryException in org.apache.drill.exec.record
ModifierConstructorDescriptionprotected
AbstractBinaryRecordBatch
(T popConfig, FragmentContext context, boolean buildSchema, RecordBatch left, RecordBatch right) protected
AbstractBinaryRecordBatch
(T popConfig, FragmentContext context, RecordBatch left, RecordBatch right) protected
AbstractRecordBatch
(T popConfig, FragmentContext context) protected
AbstractRecordBatch
(T popConfig, FragmentContext context, boolean buildSchema) AbstractSingleRecordBatch
(T popConfig, FragmentContext context, RecordBatch incoming) AbstractTableFunctionRecordBatch
(T popConfig, FragmentContext context) AbstractUnaryRecordBatch
(T popConfig, FragmentContext context) -
Uses of OutOfMemoryException in org.apache.drill.exec.store
Modifier and TypeMethodDescriptionvoid
AbstractRecordReader.allocate
(Map<String, ValueVector> vectorMap) void
RecordReader.allocate
(Map<String, ValueVector> vectorMap) -
Uses of OutOfMemoryException in org.apache.drill.exec.store.drill.plugin
ModifierConstructorDescriptionDrillRecordReader
(ExecutorFragmentContext context, DrillSubScan config) -
Uses of OutOfMemoryException in org.apache.drill.exec.store.easy.json
ModifierConstructorDescriptionJSONRecordReader
(FragmentContext fragmentContext, com.fasterxml.jackson.databind.JsonNode embeddedContent, DrillFileSystem fileSystem, List<SchemaPath> columns) Deprecated.Create a new JSON Record Reader that uses an in memory materialized JSON stream.JSONRecordReader
(FragmentContext fragmentContext, List<SchemaPath> columns) Deprecated.Create a JSON Record Reader that uses an InputStream directlyJSONRecordReader
(FragmentContext fragmentContext, org.apache.hadoop.fs.Path inputPath, DrillFileSystem fileSystem, List<SchemaPath> columns, JSONFormatConfig config) Deprecated.Create a JSON Record Reader that uses a file based input stream. -
Uses of OutOfMemoryException in org.apache.drill.exec.store.mock
Modifier and TypeMethodDescriptionvoid
MockRecordReader.allocate
(Map<String, ValueVector> vectorMap) -
Uses of OutOfMemoryException in org.apache.drill.exec.store.parquet
Modifier and TypeMethodDescriptionParquetFormatPlugin.getRecordWriter
(FragmentContext context, ParquetWriter writer) -
Uses of OutOfMemoryException in org.apache.drill.exec.store.parquet.columnreaders
Modifier and TypeMethodDescriptionvoid
ParquetRecordReader.allocate
(Map<String, ValueVector> vectorMap) -
Uses of OutOfMemoryException in org.apache.drill.exec.store.parquet.columnreaders.batchsizing
Modifier and TypeMethodDescriptionvoid
RecordBatchSizerManager.allocate
(Map<String, ValueVector> vectorMap) Allocates value vectors for the current batch. -
Uses of OutOfMemoryException in org.apache.drill.exec.store.parquet2
Modifier and TypeMethodDescriptionvoid
DrillParquetReader.allocate
(Map<String, ValueVector> vectorMap) -
Uses of OutOfMemoryException in org.apache.drill.exec.store.pojo
Modifier and TypeMethodDescriptionvoid
AbstractPojoRecordReader.allocate
(Map<String, ValueVector> vectorMap) -
Uses of OutOfMemoryException in org.apache.drill.exec.vector
Modifier and TypeMethodDescriptionvoid
ObjectVector.allocateNew()
void
ObjectVector.allocateNew
(int valueCount) void
ValueVector.allocateNew()
Allocate new buffers.void
ZeroVector.allocateNew()
-
Uses of OutOfMemoryException in org.apache.drill.exec.vector.complex
Modifier and TypeMethodDescriptionvoid
AbstractContainerVector.allocateNew()
void
ListVector.allocateNew()
void
RepeatedDictVector.allocateNew()
void
RepeatedListVector.allocateNew()
void
RepeatedListVector.DelegateRepeatedVector.allocateNew()
void
UnionVector.allocateNew()
void
UnionVector.allocateNew
(int rowCount)