Uses of Interface
org.apache.drill.exec.ops.OperatorContext
Packages that use OperatorContext
Package
Description
Defines a revised implementation of the Drill RecordBatch protocol.
Defines the scan operation implementation.
Defines the projection, vector continuity and other operations for
a set of one or more readers.
Provides the "version 3" scan framework (which can also be thought of
as EVF version 2).
Implements the details of the scan lifecycle for a set of readers,
primarily the process of resolving the scan output schema from a variety
of input schemas, then running each reader, each of which will produce
some number of batches.
Defines a mock data source which generates dummy test data for use
in testing.
MongoDB storage plugin.
-
Uses of OperatorContext in org.apache.drill.exec.ops
Classes in org.apache.drill.exec.ops that implement OperatorContextModifier and TypeClassDescriptionclass
Implementation ofOperatorContext
that provides services needed by most run-time operators.Methods in org.apache.drill.exec.ops that return OperatorContextModifier and TypeMethodDescriptionFragmentContext.newOperatorContext
(PhysicalOperator popConfig) FragmentContext.newOperatorContext
(PhysicalOperator popConfig, OperatorStats stats) FragmentContextImpl.newOperatorContext
(PhysicalOperator popConfig) FragmentContextImpl.newOperatorContext
(PhysicalOperator popConfig, OperatorStats stats) FragmentContextInterface.newOperatorContext
(PhysicalOperator popConfig) FragmentContextInterface.newOperatorContext
(PhysicalOperator popConfig, OperatorStats stats) -
Uses of OperatorContext in org.apache.drill.exec.physical.impl
Fields in org.apache.drill.exec.physical.impl declared as OperatorContextMethods in org.apache.drill.exec.physical.impl that return OperatorContextConstructors in org.apache.drill.exec.physical.impl with parameters of type OperatorContextModifierConstructorDescriptionBaseRootExec
(RootFragmentContext fragmentContext, OperatorContext oContext, PhysicalOperator config) Mutator
(OperatorContext oContext, BufferAllocator allocator, VectorContainer container) ScanBatch
(FragmentContext context, OperatorContext oContext, List<? extends RecordReader> readerList, List<Map<String, String>> implicitColumnList) -
Uses of OperatorContext in org.apache.drill.exec.physical.impl.aggregate
Methods in org.apache.drill.exec.physical.impl.aggregate with parameters of type OperatorContextModifier and TypeMethodDescriptionvoid
HashAggregator.setup
(HashAggregate hashAggrConfig, HashTableConfig htConfig, FragmentContext context, OperatorContext oContext, RecordBatch incoming, HashAggBatch outgoing, LogicalExpression[] valueExprs, List<TypedFieldId> valueFieldIds, ClassGenerator<?> cg, TypedFieldId[] keyFieldIds, VectorContainer outContainer, int extraRowBytes) void
HashAggTemplate.setup
(HashAggregate hashAggrConfig, HashTableConfig htConfig, FragmentContext context, OperatorContext oContext, RecordBatch incoming, HashAggBatch outgoing, LogicalExpression[] valueExprs, List<TypedFieldId> valueFieldIds, ClassGenerator<?> cg, TypedFieldId[] groupByOutFieldIds, VectorContainer outContainer, int extraRowBytes) void
StreamingAggregator.setup
(OperatorContext context, RecordBatch incoming, StreamingAggBatch outgoing, int outputRowCount) void
StreamingAggTemplate.setup
(OperatorContext context, RecordBatch incoming, StreamingAggBatch outgoing, int outputRowCount) Constructors in org.apache.drill.exec.physical.impl.aggregate with parameters of type OperatorContextModifierConstructorDescriptionInternalBatch
(RecordBatch incoming, OperatorContext oContext) InternalBatch
(RecordBatch incoming, VectorWrapper<?>[] ignoreWrappers, OperatorContext oContext) SpilledRecordBatch
(String spillFile, int spilledBatches, FragmentContext context, BatchSchema schema, OperatorContext oContext, SpillSet spillSet) -
Uses of OperatorContext in org.apache.drill.exec.physical.impl.materialize
Constructors in org.apache.drill.exec.physical.impl.materialize with parameters of type OperatorContextModifierConstructorDescriptionVectorRecordMaterializer
(FragmentContext context, OperatorContext oContext, RecordBatch batch) -
Uses of OperatorContext in org.apache.drill.exec.physical.impl.partitionsender
Methods in org.apache.drill.exec.physical.impl.partitionsender with parameters of type OperatorContextModifier and TypeMethodDescriptionvoid
Partitioner.setup
(ExchangeFragmentContext context, RecordBatch incoming, HashPartitionSender popConfig, OperatorStats stats, OperatorContext oContext, ClassGenerator<?> cg, int start, int count) final void
PartitionerTemplate.setup
(ExchangeFragmentContext context, RecordBatch incoming, HashPartitionSender popConfig, OperatorStats stats, OperatorContext oContext, ClassGenerator<?> cg, int start, int end) -
Uses of OperatorContext in org.apache.drill.exec.physical.impl.protocol
Methods in org.apache.drill.exec.physical.impl.protocol that return OperatorContextMethods in org.apache.drill.exec.physical.impl.protocol with parameters of type OperatorContextModifier and TypeMethodDescriptionvoid
OperatorExec.bind
(OperatorContext context) Bind this operator to the context.Constructors in org.apache.drill.exec.physical.impl.protocol with parameters of type OperatorContextModifierConstructorDescriptionOperatorDriver
(OperatorContext opContext, OperatorExec opExec, boolean enableSchemaBatch) -
Uses of OperatorContext in org.apache.drill.exec.physical.impl.scan
Fields in org.apache.drill.exec.physical.impl.scan declared as OperatorContextMethods in org.apache.drill.exec.physical.impl.scan that return OperatorContextMethods in org.apache.drill.exec.physical.impl.scan with parameters of type OperatorContextModifier and TypeMethodDescriptionvoid
ScanOperatorEvents.bind
(OperatorContext context) Build the scan-level schema from the physical operator select list.void
ScanOperatorExec.bind
(OperatorContext context) -
Uses of OperatorContext in org.apache.drill.exec.physical.impl.scan.framework
Fields in org.apache.drill.exec.physical.impl.scan.framework declared as OperatorContextMethods in org.apache.drill.exec.physical.impl.scan.framework that return OperatorContextModifier and TypeMethodDescriptionManagedScanFramework.context()
SchemaNegotiator.context()
SchemaNegotiatorImpl.context()
Methods in org.apache.drill.exec.physical.impl.scan.framework with parameters of type OperatorContext -
Uses of OperatorContext in org.apache.drill.exec.physical.impl.scan.v3
Methods in org.apache.drill.exec.physical.impl.scan.v3 that return OperatorContextMethods in org.apache.drill.exec.physical.impl.scan.v3 with parameters of type OperatorContext -
Uses of OperatorContext in org.apache.drill.exec.physical.impl.scan.v3.file
Methods in org.apache.drill.exec.physical.impl.scan.v3.file with parameters of type OperatorContextConstructors in org.apache.drill.exec.physical.impl.scan.v3.file with parameters of type OperatorContextModifierConstructorDescriptionFileScanLifecycle
(OperatorContext context, FileScanLifecycleBuilder options) -
Uses of OperatorContext in org.apache.drill.exec.physical.impl.scan.v3.lifecycle
Methods in org.apache.drill.exec.physical.impl.scan.v3.lifecycle that return OperatorContextMethods in org.apache.drill.exec.physical.impl.scan.v3.lifecycle with parameters of type OperatorContextConstructors in org.apache.drill.exec.physical.impl.scan.v3.lifecycle with parameters of type OperatorContextModifierConstructorDescriptionScanLifecycle
(OperatorContext context, ScanLifecycleBuilder builder) -
Uses of OperatorContext in org.apache.drill.exec.physical.impl.window
Methods in org.apache.drill.exec.physical.impl.window that return OperatorContextMethods in org.apache.drill.exec.physical.impl.window with parameters of type OperatorContextModifier and TypeMethodDescriptionvoid
FrameSupportTemplate.setup
(List<WindowDataBatch> batches, VectorContainer container, OperatorContext oContext, boolean requireFullPartition, WindowPOP popConfig) void
NoFrameSupportTemplate.setup
(List<WindowDataBatch> batches, VectorContainer container, OperatorContext oContext, boolean requireFullPartition, WindowPOP popConfig) void
WindowFramer.setup
(List<WindowDataBatch> batches, VectorContainer container, OperatorContext operatorContext, boolean requireFullPartition, WindowPOP popConfig) Constructors in org.apache.drill.exec.physical.impl.window with parameters of type OperatorContext -
Uses of OperatorContext in org.apache.drill.exec.physical.impl.xsort
Fields in org.apache.drill.exec.physical.impl.xsort declared as OperatorContextMethods in org.apache.drill.exec.physical.impl.xsort that return OperatorContextConstructors in org.apache.drill.exec.physical.impl.xsort with parameters of type OperatorContextModifierConstructorDescriptionBaseSortWrapper
(OperatorContext opContext) BaseWrapper
(OperatorContext context) BufferedBatches
(OperatorContext opContext) MergeSortWrapper
(OperatorContext opContext, VectorContainer destContainer) PriorityQueueCopierWrapper
(OperatorContext opContext) SorterWrapper
(OperatorContext opContext) SortImpl
(OperatorContext opContext, SortConfig sortConfig, SpilledRuns spilledRuns, VectorContainer batch) SpilledRuns
(OperatorContext opContext, SpillSet spillSet, PriorityQueueCopierWrapper copier) -
Uses of OperatorContext in org.apache.drill.exec.planner.sql.handlers
Methods in org.apache.drill.exec.planner.sql.handlers with parameters of type OperatorContextModifier and TypeMethodDescriptionvoid
FindLimit0Visitor.RelDataTypeReader.setup
(OperatorContext context, OutputMutator output) -
Uses of OperatorContext in org.apache.drill.exec.record
Fields in org.apache.drill.exec.record declared as OperatorContextMethods in org.apache.drill.exec.record with parameters of type OperatorContextModifier and TypeMethodDescriptionstatic VectorContainer
SchemaUtil.coerceContainer
(VectorAccessible in, BatchSchema toSchema, OperatorContext context) Creates a copy a record batch, converting any fields as necessary to coerce it into the provided schemastatic VectorContainer
VectorContainer.getTransferClone
(VectorAccessible incoming, OperatorContext oContext) Get a set of transferred clones of this container.static VectorContainer
VectorContainer.getTransferClone
(VectorAccessible incoming, VectorWrapper<?>[] ignoreWrappers, OperatorContext oContext) Constructors in org.apache.drill.exec.record with parameters of type OperatorContextModifierConstructorDescriptionprotected
AbstractRecordBatch
(T popConfig, FragmentContext context, boolean buildSchema, OperatorContext oContext) RecordIterator
(RecordBatch incoming, AbstractRecordBatch<?> outgoing, OperatorContext oContext, int inputIndex, boolean enableMarkAndReset, RecordBatchMemoryManager callBack) RecordIterator
(RecordBatch incoming, AbstractRecordBatch<?> outgoing, OperatorContext oContext, int inputIndex, RecordBatchMemoryManager callBack) VectorContainer
(OperatorContext oContext) -
Uses of OperatorContext in org.apache.drill.exec.store
Fields in org.apache.drill.exec.store declared as OperatorContextModifier and TypeFieldDescriptionprotected OperatorContext
CommonParquetRecordReader.operatorContext
Methods in org.apache.drill.exec.store with parameters of type OperatorContextModifier and TypeMethodDescriptionvoid
RecordReader.setup
(OperatorContext context, OutputMutator output) Configure the RecordReader with the provided schema and the record batch that should be written to. -
Uses of OperatorContext in org.apache.drill.exec.store.delta.read
Methods in org.apache.drill.exec.store.delta.read with parameters of type OperatorContextModifier and TypeMethodDescriptionDeltaScanBatchCreator.getDrillFileSystemCreator
(OperatorContext operatorContext, OptionManager optionManager) -
Uses of OperatorContext in org.apache.drill.exec.store.druid
Methods in org.apache.drill.exec.store.druid with parameters of type OperatorContextModifier and TypeMethodDescriptionvoid
DruidRecordReader.setup
(OperatorContext context, OutputMutator output) -
Uses of OperatorContext in org.apache.drill.exec.store.easy.json
Methods in org.apache.drill.exec.store.easy.json with parameters of type OperatorContextModifier and TypeMethodDescriptionvoid
JSONRecordReader.setup
(OperatorContext context, OutputMutator output) Deprecated. -
Uses of OperatorContext in org.apache.drill.exec.store.googlesheets
Constructors in org.apache.drill.exec.store.googlesheets with parameters of type OperatorContextModifierConstructorDescriptionGoogleSheetsBatchInsertWriter
(OperatorContext context, String name, GoogleSheetsWriter config) GoogleSheetsBatchWriter
(OperatorContext context, String name, GoogleSheetsWriter config) -
Uses of OperatorContext in org.apache.drill.exec.store.hbase
Methods in org.apache.drill.exec.store.hbase with parameters of type OperatorContextModifier and TypeMethodDescriptionvoid
HBaseRecordReader.setup
(OperatorContext context, OutputMutator output) -
Uses of OperatorContext in org.apache.drill.exec.store.hive
Methods in org.apache.drill.exec.store.hive with parameters of type OperatorContextModifier and TypeMethodDescriptionHiveDrillNativeParquetScanBatchCreator.getDrillFileSystemCreator
(OperatorContext operatorContext, OptionManager optionManager) -
Uses of OperatorContext in org.apache.drill.exec.store.hive.readers
Methods in org.apache.drill.exec.store.hive.readers with parameters of type OperatorContextModifier and TypeMethodDescriptionvoid
HiveDefaultRecordReader.setup
(OperatorContext context, OutputMutator output) -
Uses of OperatorContext in org.apache.drill.exec.store.kudu
Methods in org.apache.drill.exec.store.kudu with parameters of type OperatorContextModifier and TypeMethodDescriptionvoid
KuduRecordReader.setup
(OperatorContext context, OutputMutator output) Constructors in org.apache.drill.exec.store.kudu with parameters of type OperatorContextModifierConstructorDescriptionKuduRecordWriterImpl
(OperatorContext context, org.apache.kudu.client.KuduClient client, String name) -
Uses of OperatorContext in org.apache.drill.exec.store.mock
Methods in org.apache.drill.exec.store.mock with parameters of type OperatorContextModifier and TypeMethodDescriptionvoid
MockRecordReader.setup
(OperatorContext context, OutputMutator output) -
Uses of OperatorContext in org.apache.drill.exec.store.mongo
Methods in org.apache.drill.exec.store.mongo with parameters of type OperatorContextModifier and TypeMethodDescriptionvoid
MongoRecordReader.setup
(OperatorContext context, OutputMutator output) -
Uses of OperatorContext in org.apache.drill.exec.store.openTSDB
Methods in org.apache.drill.exec.store.openTSDB with parameters of type OperatorContextModifier and TypeMethodDescriptionvoid
OpenTSDBRecordReader.setup
(OperatorContext context, OutputMutator output) -
Uses of OperatorContext in org.apache.drill.exec.store.parquet
Fields in org.apache.drill.exec.store.parquet declared as OperatorContextModifier and TypeFieldDescriptionprotected final OperatorContext
AbstractParquetScanBatchCreator.AbstractDrillFileSystemManager.operatorContext
Methods in org.apache.drill.exec.store.parquet with parameters of type OperatorContextModifier and TypeMethodDescriptionprotected ScanBatch
AbstractParquetScanBatchCreator.getBatch
(ExecutorFragmentContext context, AbstractParquetRowGroupScan rowGroupScan, OperatorContext oContext) protected abstract AbstractParquetScanBatchCreator.AbstractDrillFileSystemManager
AbstractParquetScanBatchCreator.getDrillFileSystemCreator
(OperatorContext operatorContext, OptionManager optionManager) ParquetScanBatchCreator.getDrillFileSystemCreator
(OperatorContext operatorContext, OptionManager optionManager) Constructors in org.apache.drill.exec.store.parquet with parameters of type OperatorContextModifierConstructorDescriptionprotected
AbstractDrillFileSystemManager
(OperatorContext operatorContext) ParquetDrillFileSystemManager
(OperatorContext operatorContext, boolean useAsyncPageReader) -
Uses of OperatorContext in org.apache.drill.exec.store.parquet.columnreaders
Methods in org.apache.drill.exec.store.parquet.columnreaders that return OperatorContextMethods in org.apache.drill.exec.store.parquet.columnreaders with parameters of type OperatorContextModifier and TypeMethodDescriptionvoid
ParquetRecordReader.setup
(OperatorContext operatorContext, OutputMutator output) Prepare the Parquet reader. -
Uses of OperatorContext in org.apache.drill.exec.store.parquet2
Methods in org.apache.drill.exec.store.parquet2 with parameters of type OperatorContextModifier and TypeMethodDescriptionvoid
DrillParquetReader.setup
(OperatorContext context, OutputMutator output) -
Uses of OperatorContext in org.apache.drill.exec.store.pojo
Methods in org.apache.drill.exec.store.pojo with parameters of type OperatorContextModifier and TypeMethodDescriptionvoid
AbstractPojoRecordReader.setup
(OperatorContext context, OutputMutator output) -
Uses of OperatorContext in org.apache.drill.exec.util.record
Constructors in org.apache.drill.exec.util.record with parameters of type OperatorContextModifierConstructorDescriptionRecordBatchStatsContext
(FragmentContext context, OperatorContext oContext)