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.opsClasses in org.apache.drill.exec.ops that implement OperatorContextModifier and TypeClassDescriptionclassImplementation ofOperatorContextthat 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.implFields 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.aggregateMethods in org.apache.drill.exec.physical.impl.aggregate with parameters of type OperatorContextModifier and TypeMethodDescriptionvoidHashAggregator.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) voidHashAggTemplate.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) voidStreamingAggregator.setup(OperatorContext context, RecordBatch incoming, StreamingAggBatch outgoing, int outputRowCount) voidStreamingAggTemplate.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.materializeConstructors 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.partitionsenderMethods in org.apache.drill.exec.physical.impl.partitionsender with parameters of type OperatorContextModifier and TypeMethodDescriptionvoidPartitioner.setup(ExchangeFragmentContext context, RecordBatch incoming, HashPartitionSender popConfig, OperatorStats stats, OperatorContext oContext, ClassGenerator<?> cg, int start, int count) final voidPartitionerTemplate.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.protocolMethods 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 TypeMethodDescriptionvoidOperatorExec.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.scanFields 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 TypeMethodDescriptionvoidScanOperatorEvents.bind(OperatorContext context) Build the scan-level schema from the physical operator select list.voidScanOperatorExec.bind(OperatorContext context) 
- 
Uses of OperatorContext in org.apache.drill.exec.physical.impl.scan.frameworkFields 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.v3Methods 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.fileMethods 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.lifecycleMethods 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.windowMethods 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 TypeMethodDescriptionvoidFrameSupportTemplate.setup(List<WindowDataBatch> batches, VectorContainer container, OperatorContext oContext, boolean requireFullPartition, WindowPOP popConfig) voidNoFrameSupportTemplate.setup(List<WindowDataBatch> batches, VectorContainer container, OperatorContext oContext, boolean requireFullPartition, WindowPOP popConfig) voidWindowFramer.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.xsortFields 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.handlersMethods in org.apache.drill.exec.planner.sql.handlers with parameters of type OperatorContextModifier and TypeMethodDescriptionvoidFindLimit0Visitor.RelDataTypeReader.setup(OperatorContext context, OutputMutator output) 
- 
Uses of OperatorContext in org.apache.drill.exec.recordFields in org.apache.drill.exec.record declared as OperatorContextMethods in org.apache.drill.exec.record with parameters of type OperatorContextModifier and TypeMethodDescriptionstatic VectorContainerSchemaUtil.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 VectorContainerVectorContainer.getTransferClone(VectorAccessible incoming, OperatorContext oContext) Get a set of transferred clones of this container.static VectorContainerVectorContainer.getTransferClone(VectorAccessible incoming, VectorWrapper<?>[] ignoreWrappers, OperatorContext oContext) Constructors in org.apache.drill.exec.record with parameters of type OperatorContextModifierConstructorDescriptionprotectedAbstractRecordBatch(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.storeFields in org.apache.drill.exec.store declared as OperatorContextModifier and TypeFieldDescriptionprotected OperatorContextCommonParquetRecordReader.operatorContextMethods in org.apache.drill.exec.store with parameters of type OperatorContextModifier and TypeMethodDescriptionvoidRecordReader.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.readMethods 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.druidMethods in org.apache.drill.exec.store.druid with parameters of type OperatorContextModifier and TypeMethodDescriptionvoidDruidRecordReader.setup(OperatorContext context, OutputMutator output) 
- 
Uses of OperatorContext in org.apache.drill.exec.store.easy.jsonMethods in org.apache.drill.exec.store.easy.json with parameters of type OperatorContextModifier and TypeMethodDescriptionvoidJSONRecordReader.setup(OperatorContext context, OutputMutator output) Deprecated.
- 
Uses of OperatorContext in org.apache.drill.exec.store.googlesheetsConstructors 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.hbaseMethods in org.apache.drill.exec.store.hbase with parameters of type OperatorContextModifier and TypeMethodDescriptionvoidHBaseRecordReader.setup(OperatorContext context, OutputMutator output) 
- 
Uses of OperatorContext in org.apache.drill.exec.store.hiveMethods 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.readersMethods in org.apache.drill.exec.store.hive.readers with parameters of type OperatorContextModifier and TypeMethodDescriptionvoidHiveDefaultRecordReader.setup(OperatorContext context, OutputMutator output) 
- 
Uses of OperatorContext in org.apache.drill.exec.store.kuduMethods in org.apache.drill.exec.store.kudu with parameters of type OperatorContextModifier and TypeMethodDescriptionvoidKuduRecordReader.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.mockMethods in org.apache.drill.exec.store.mock with parameters of type OperatorContextModifier and TypeMethodDescriptionvoidMockRecordReader.setup(OperatorContext context, OutputMutator output) 
- 
Uses of OperatorContext in org.apache.drill.exec.store.mongoMethods in org.apache.drill.exec.store.mongo with parameters of type OperatorContextModifier and TypeMethodDescriptionvoidMongoRecordReader.setup(OperatorContext context, OutputMutator output) 
- 
Uses of OperatorContext in org.apache.drill.exec.store.openTSDBMethods in org.apache.drill.exec.store.openTSDB with parameters of type OperatorContextModifier and TypeMethodDescriptionvoidOpenTSDBRecordReader.setup(OperatorContext context, OutputMutator output) 
- 
Uses of OperatorContext in org.apache.drill.exec.store.parquetFields in org.apache.drill.exec.store.parquet declared as OperatorContextModifier and TypeFieldDescriptionprotected final OperatorContextAbstractParquetScanBatchCreator.AbstractDrillFileSystemManager.operatorContextMethods in org.apache.drill.exec.store.parquet with parameters of type OperatorContextModifier and TypeMethodDescriptionprotected ScanBatchAbstractParquetScanBatchCreator.getBatch(ExecutorFragmentContext context, AbstractParquetRowGroupScan rowGroupScan, OperatorContext oContext) protected abstract AbstractParquetScanBatchCreator.AbstractDrillFileSystemManagerAbstractParquetScanBatchCreator.getDrillFileSystemCreator(OperatorContext operatorContext, OptionManager optionManager) ParquetScanBatchCreator.getDrillFileSystemCreator(OperatorContext operatorContext, OptionManager optionManager) Constructors in org.apache.drill.exec.store.parquet with parameters of type OperatorContextModifierConstructorDescriptionprotectedAbstractDrillFileSystemManager(OperatorContext operatorContext) ParquetDrillFileSystemManager(OperatorContext operatorContext, boolean useAsyncPageReader) 
- 
Uses of OperatorContext in org.apache.drill.exec.store.parquet.columnreadersMethods 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 TypeMethodDescriptionvoidParquetRecordReader.setup(OperatorContext operatorContext, OutputMutator output) Prepare the Parquet reader.
- 
Uses of OperatorContext in org.apache.drill.exec.store.parquet2Methods in org.apache.drill.exec.store.parquet2 with parameters of type OperatorContextModifier and TypeMethodDescriptionvoidDrillParquetReader.setup(OperatorContext context, OutputMutator output) 
- 
Uses of OperatorContext in org.apache.drill.exec.store.pojoMethods in org.apache.drill.exec.store.pojo with parameters of type OperatorContextModifier and TypeMethodDescriptionvoidAbstractPojoRecordReader.setup(OperatorContext context, OutputMutator output) 
- 
Uses of OperatorContext in org.apache.drill.exec.util.recordConstructors in org.apache.drill.exec.util.record with parameters of type OperatorContextModifierConstructorDescriptionRecordBatchStatsContext(FragmentContext context, OperatorContext oContext)