Uses of Class
org.apache.drill.exec.exception.OutOfMemoryException
Packages that use 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
Constructors in org.apache.drill.exec.client that throw OutOfMemoryExceptionModifierConstructorDescriptionDrillClient
(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
Constructors in org.apache.drill.exec.memory that throw OutOfMemoryExceptionModifierConstructorDescriptionprotected
BaseAllocator
(BaseAllocator parentAllocator, String name, long initReservation, long maxAllocation) -
Uses of OutOfMemoryException in org.apache.drill.exec.ops
Methods in org.apache.drill.exec.ops that throw OutOfMemoryExceptionModifier 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
Methods in org.apache.drill.exec.physical.impl that throw OutOfMemoryExceptionModifier and TypeMethodDescriptionMergingReceiverCreator.getBatch
(ExecutorFragmentContext context, MergingReceiverPOP receiver, List<RecordBatch> children) Constructors in org.apache.drill.exec.physical.impl that throw OutOfMemoryExceptionModifierConstructorDescriptionBaseRootExec
(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
Constructors in org.apache.drill.exec.physical.impl.aggregate that throw OutOfMemoryExceptionModifierConstructorDescriptionStreamingAggBatch
(StreamingAggregate popConfig, RecordBatch incoming, FragmentContext context) -
Uses of OutOfMemoryException in org.apache.drill.exec.physical.impl.broadcastsender
Constructors in org.apache.drill.exec.physical.impl.broadcastsender that throw OutOfMemoryExceptionModifierConstructorDescriptionBroadcastSenderRootExec
(RootFragmentContext context, RecordBatch incoming, BroadcastSender config) -
Uses of OutOfMemoryException in org.apache.drill.exec.physical.impl.filter
Constructors in org.apache.drill.exec.physical.impl.filter that throw OutOfMemoryExceptionModifierConstructorDescriptionFilterRecordBatch
(Filter pop, RecordBatch incoming, FragmentContext context) RuntimeFilterRecordBatch
(RuntimeFilterPOP pop, RecordBatch incoming, FragmentContext context) -
Uses of OutOfMemoryException in org.apache.drill.exec.physical.impl.flatten
Constructors in org.apache.drill.exec.physical.impl.flatten that throw OutOfMemoryExceptionModifierConstructorDescriptionFlattenRecordBatch
(FlattenPOP pop, RecordBatch incoming, FragmentContext context) -
Uses of OutOfMemoryException in org.apache.drill.exec.physical.impl.join
Constructors in org.apache.drill.exec.physical.impl.join that throw OutOfMemoryExceptionModifierConstructorDescriptionAbstractHashBinaryRecordBatch
(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
Constructors in org.apache.drill.exec.physical.impl.limit that throw OutOfMemoryExceptionModifierConstructorDescriptionLimitRecordBatch
(Limit popConfig, FragmentContext context, RecordBatch incoming) PartitionLimitRecordBatch
(PartitionLimit popConfig, FragmentContext context, RecordBatch incoming) -
Uses of OutOfMemoryException in org.apache.drill.exec.physical.impl.mergereceiver
Constructors in org.apache.drill.exec.physical.impl.mergereceiver that throw OutOfMemoryExceptionModifierConstructorDescriptionMergingRecordBatch
(ExchangeFragmentContext context, MergingReceiverPOP config, RawFragmentBatchProvider[] fragProviders) -
Uses of OutOfMemoryException in org.apache.drill.exec.physical.impl.metadata
Constructors in org.apache.drill.exec.physical.impl.metadata that throw OutOfMemoryExceptionModifierConstructorDescriptionprotected
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
Constructors in org.apache.drill.exec.physical.impl.orderedpartitioner that throw OutOfMemoryExceptionModifierConstructorDescriptionOrderedPartitionRecordBatch
(OrderedPartitionSender pop, RecordBatch incoming, FragmentContext context) -
Uses of OutOfMemoryException in org.apache.drill.exec.physical.impl.partitionsender
Constructors in org.apache.drill.exec.physical.impl.partitionsender that throw OutOfMemoryExceptionModifierConstructorDescriptionPartitionSenderRootExec
(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
Constructors in org.apache.drill.exec.physical.impl.producer that throw OutOfMemoryExceptionModifierConstructorDescriptionprotected
ProducerConsumerBatch
(ProducerConsumer popConfig, FragmentContext context, RecordBatch incoming) -
Uses of OutOfMemoryException in org.apache.drill.exec.physical.impl.rangepartitioner
Constructors in org.apache.drill.exec.physical.impl.rangepartitioner that throw OutOfMemoryExceptionModifierConstructorDescriptionRangePartitionRecordBatch
(RangePartitionSender popConfig, RecordBatch incoming, FragmentContext context) -
Uses of OutOfMemoryException in org.apache.drill.exec.physical.impl.setop
Constructors in org.apache.drill.exec.physical.impl.setop that throw OutOfMemoryExceptionModifierConstructorDescriptionHashSetOpRecordBatch
(SetOp popConfig, FragmentContext context, RecordBatch left, RecordBatch right) The constructor -
Uses of OutOfMemoryException in org.apache.drill.exec.physical.impl.sort
Constructors in org.apache.drill.exec.physical.impl.sort that throw OutOfMemoryExceptionModifierConstructorDescriptionSortBatch
(Sort popConfig, FragmentContext context, RecordBatch incoming) -
Uses of OutOfMemoryException in org.apache.drill.exec.physical.impl.statistics
Constructors in org.apache.drill.exec.physical.impl.statistics that throw OutOfMemoryExceptionModifierConstructorDescriptionStatisticsAggBatch
(StatisticsAggregate popConfig, RecordBatch incoming, FragmentContext context) StatisticsMergeBatch
(StatisticsMerge popConfig, RecordBatch incoming, FragmentContext context) -
Uses of OutOfMemoryException in org.apache.drill.exec.physical.impl.svremover
Constructors in org.apache.drill.exec.physical.impl.svremover that throw OutOfMemoryExceptionModifierConstructorDescriptionRemovingRecordBatch
(SelectionVectorRemover popConfig, FragmentContext context, RecordBatch incoming) -
Uses of OutOfMemoryException in org.apache.drill.exec.physical.impl.TopN
Constructors in org.apache.drill.exec.physical.impl.TopN that throw OutOfMemoryExceptionModifierConstructorDescriptionTopNBatch
(TopN popConfig, FragmentContext context, RecordBatch incoming) -
Uses of OutOfMemoryException in org.apache.drill.exec.physical.impl.union
Constructors in org.apache.drill.exec.physical.impl.union that throw OutOfMemoryExceptionModifierConstructorDescriptionUnionAllRecordBatch
(UnionAll config, List<RecordBatch> children, FragmentContext context) -
Uses of OutOfMemoryException in org.apache.drill.exec.physical.impl.unnest
Constructors in org.apache.drill.exec.physical.impl.unnest that throw OutOfMemoryException -
Uses of OutOfMemoryException in org.apache.drill.exec.physical.impl.unorderedreceiver
Constructors in org.apache.drill.exec.physical.impl.unorderedreceiver that throw OutOfMemoryExceptionModifierConstructorDescriptionUnorderedReceiverBatch
(ExchangeFragmentContext context, RawFragmentBatchProvider fragProvider, UnorderedReceiver config) -
Uses of OutOfMemoryException in org.apache.drill.exec.physical.impl.unpivot
Constructors in org.apache.drill.exec.physical.impl.unpivot that throw OutOfMemoryExceptionModifierConstructorDescriptionUnpivotMapsRecordBatch
(UnpivotMaps pop, RecordBatch incoming, FragmentContext context) -
Uses of OutOfMemoryException in org.apache.drill.exec.physical.impl.window
Constructors in org.apache.drill.exec.physical.impl.window that throw OutOfMemoryExceptionModifierConstructorDescriptionWindowFrameRecordBatch
(WindowPOP popConfig, FragmentContext context, RecordBatch incoming) -
Uses of OutOfMemoryException in org.apache.drill.exec.record
Constructors in org.apache.drill.exec.record that throw OutOfMemoryExceptionModifierConstructorDescriptionprotected
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
Methods in org.apache.drill.exec.store that throw OutOfMemoryExceptionModifier 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
Constructors in org.apache.drill.exec.store.drill.plugin that throw OutOfMemoryExceptionModifierConstructorDescriptionDrillRecordReader
(ExecutorFragmentContext context, DrillSubScan config) -
Uses of OutOfMemoryException in org.apache.drill.exec.store.easy.json
Constructors in org.apache.drill.exec.store.easy.json that throw OutOfMemoryExceptionModifierConstructorDescriptionJSONRecordReader
(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
Methods in org.apache.drill.exec.store.mock that throw OutOfMemoryExceptionModifier and TypeMethodDescriptionvoid
MockRecordReader.allocate
(Map<String, ValueVector> vectorMap) -
Uses of OutOfMemoryException in org.apache.drill.exec.store.parquet
Methods in org.apache.drill.exec.store.parquet that throw OutOfMemoryExceptionModifier and TypeMethodDescriptionParquetFormatPlugin.getRecordWriter
(FragmentContext context, ParquetWriter writer) Constructors in org.apache.drill.exec.store.parquet that throw OutOfMemoryException -
Uses of OutOfMemoryException in org.apache.drill.exec.store.parquet.columnreaders
Methods in org.apache.drill.exec.store.parquet.columnreaders that throw OutOfMemoryExceptionModifier and TypeMethodDescriptionvoid
ParquetRecordReader.allocate
(Map<String, ValueVector> vectorMap) -
Uses of OutOfMemoryException in org.apache.drill.exec.store.parquet.columnreaders.batchsizing
Methods in org.apache.drill.exec.store.parquet.columnreaders.batchsizing that throw OutOfMemoryExceptionModifier 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
Methods in org.apache.drill.exec.store.parquet2 that throw OutOfMemoryExceptionModifier and TypeMethodDescriptionvoid
DrillParquetReader.allocate
(Map<String, ValueVector> vectorMap) -
Uses of OutOfMemoryException in org.apache.drill.exec.store.pojo
Methods in org.apache.drill.exec.store.pojo that throw OutOfMemoryExceptionModifier and TypeMethodDescriptionvoid
AbstractPojoRecordReader.allocate
(Map<String, ValueVector> vectorMap) -
Uses of OutOfMemoryException in org.apache.drill.exec.vector
Methods in org.apache.drill.exec.vector that throw OutOfMemoryExceptionModifier 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
Methods in org.apache.drill.exec.vector.complex that throw OutOfMemoryExceptionModifier 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)