Uses of Interface
org.apache.drill.exec.ops.FragmentContext
Packages that use FragmentContext
Package
Description
Defines a revised implementation of the Drill RecordBatch protocol.
Provides run-time semantic analysis of the projection list for the
scan operator.
Provides the "version 3" scan framework (which can also be thought of
as EVF version 2).
Collection of classes shared by operators that implement spill-to-disk.
Drill storage plugin.
Defines a mock data source which generates dummy test data for use
in testing.
MongoDB storage plugin.
-
Uses of FragmentContext in org.apache.drill.exec.expr.fn.impl
Constructors in org.apache.drill.exec.expr.fn.impl with parameters of type FragmentContextModifierConstructorDescriptionValueVectorHashHelper
(RecordBatch recordBatch, FragmentContext context) -
Uses of FragmentContext in org.apache.drill.exec.ops
Subinterfaces of FragmentContext in org.apache.drill.exec.opsModifier and TypeInterfaceDescriptioninterface
This provides the resources required by an exchange operator.interface
The context that is used by a Drillbit in classes like theFragmentExecutor
.interface
Provides services needed by theFragmentExecutor
.Classes in org.apache.drill.exec.ops that implement FragmentContextModifier and TypeClassDescriptionclass
Common implementation for both the test and production versions of the fragment context.class
This is the core Context which implements all the Context interfaces:FragmentContext
: A context provided to non-exchange operators.ExchangeFragmentContext
: A context provided to exchange operators.RootFragmentContext
: A context provided to fragment roots.ExecutorFragmentContext
: A context used by the Drillbit. The interfaces above expose resources to varying degrees.Fields in org.apache.drill.exec.ops declared as FragmentContextMethods in org.apache.drill.exec.ops that return FragmentContextModifier and TypeMethodDescriptionBaseOperatorContext.getFragmentContext()
OperatorContext.getFragmentContext()
Constructors in org.apache.drill.exec.ops with parameters of type FragmentContextModifierConstructorDescriptionBaseOperatorContext
(FragmentContext context, BufferAllocator allocator, PhysicalOperator popConfig) -
Uses of FragmentContext in org.apache.drill.exec.physical.base
Methods in org.apache.drill.exec.physical.base with parameters of type FragmentContextModifier and TypeMethodDescriptionstatic LogicalExpression
PhysicalOperatorUtil.materializeExpression
(LogicalExpression expr, VectorAccessible incoming, FragmentContext context) Helper method to materialize the given logical expression using theExpressionTreeMaterializer
. -
Uses of FragmentContext in org.apache.drill.exec.physical.impl
Methods in org.apache.drill.exec.physical.impl that return FragmentContextMethods in org.apache.drill.exec.physical.impl with parameters of type FragmentContextModifier and TypeMethodDescriptionstatic PhysicalOperator
TraceInjector.getExec
(FragmentContext context, FragmentRoot root) TraceInjector.visitOp
(PhysicalOperator op, FragmentContext context) Traverse the physical plan and inject the trace operator after every operator.Constructors in org.apache.drill.exec.physical.impl with parameters of type FragmentContextModifierConstructorDescriptionInsertWriterRecordBatch
(Writer writer, RecordBatch incoming, FragmentContext context, RecordWriter recordWriter) ScanBatch
(FragmentContext context, OperatorContext oContext, List<? extends RecordReader> readerList, List<Map<String, String>> implicitColumnList) ScanBatch
(PhysicalOperator subScanConfig, FragmentContext context, List<RecordReader> readers) ScanBatch
(PhysicalOperator subScanConfig, FragmentContext context, List<RecordReader> readerList, boolean isRepeatableScan) StatisticsWriterRecordBatch
(Writer writer, RecordBatch incoming, FragmentContext context, StatisticsRecordWriter recordWriter) WriterRecordBatch
(Writer writer, RecordBatch incoming, FragmentContext context, RecordWriter recordWriter) -
Uses of FragmentContext in org.apache.drill.exec.physical.impl.aggregate
Fields in org.apache.drill.exec.physical.impl.aggregate declared as FragmentContextMethods in org.apache.drill.exec.physical.impl.aggregate that return FragmentContextMethods in org.apache.drill.exec.physical.impl.aggregate with parameters of type FragmentContextModifier 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) Constructors in org.apache.drill.exec.physical.impl.aggregate with parameters of type FragmentContextModifierConstructorDescriptionHashAggBatch
(HashAggregate popConfig, RecordBatch incoming, FragmentContext context) SpilledRecordBatch
(String spillFile, int spilledBatches, FragmentContext context, BatchSchema schema, OperatorContext oContext, SpillSet spillSet) StreamingAggBatch
(StreamingAggregate popConfig, RecordBatch incoming, FragmentContext context) -
Uses of FragmentContext in org.apache.drill.exec.physical.impl.common
Fields in org.apache.drill.exec.physical.impl.common declared as FragmentContextMethods in org.apache.drill.exec.physical.impl.common with parameters of type FragmentContextModifier and TypeMethodDescriptionstatic void
CodeGenMemberInjector.injectMembers
(ClassGenerator<?> cg, Object instance, FragmentContext context) Generated code for a class may have several class members, they are initialized by invoking this method when the instance created.void
HashTable.setup
(HashTableConfig htConfig, BufferAllocator allocator, VectorContainer incomingBuild, RecordBatch incomingProbe, RecordBatch outgoing, VectorContainer htContainerOrig, FragmentContext context, ClassGenerator<?> cg) HashTable.setup(org.apache.drill.exec.physical.impl.common.HashTableConfig, org.apache.drill.exec.memory.BufferAllocator, org.apache.drill.exec.record.VectorContainer, org.apache.drill.exec.record.RecordBatch, org.apache.drill.exec.record.RecordBatch, org.apache.drill.exec.record.VectorContainer, org.apache.drill.exec.ops.FragmentContext, org.apache.drill.exec.expr.ClassGenerator<?>)
must be called before anything can be done to theHashTable
.void
HashTableTemplate.setup
(HashTableConfig htConfig, BufferAllocator allocator, VectorContainer incomingBuild, RecordBatch incomingProbe, RecordBatch outgoing, VectorContainer htContainerOrig, FragmentContext context, ClassGenerator<?> cg) Constructors in org.apache.drill.exec.physical.impl.common with parameters of type FragmentContextModifierConstructorDescriptionChainedHashTable
(HashTableConfig htConfig, FragmentContext context, BufferAllocator allocator, RecordBatch incomingBuild, RecordBatch incomingProbe, RecordBatch outgoing) HashPartition
(FragmentContext context, BufferAllocator allocator, ChainedHashTable baseHashTable, RecordBatch buildBatch, RecordBatch probeBatch, boolean semiJoin, int recordsPerBatch, SpillSet spillSet, int partNum, int cycleNum, int numPartitions) -
Uses of FragmentContext in org.apache.drill.exec.physical.impl.filter
Methods in org.apache.drill.exec.physical.impl.filter that return FragmentContextModifier and TypeMethodDescriptionFilterRecordBatch.getContext()
RuntimeFilterRecordBatch.getContext()
Methods in org.apache.drill.exec.physical.impl.filter with parameters of type FragmentContextModifier and TypeMethodDescriptionabstract void
FilterTemplate2.doSetup
(FragmentContext context, RecordBatch incoming, RecordBatch outgoing) abstract void
FilterTemplate4.doSetup
(FragmentContext context, RecordBatch incoming, RecordBatch outgoing) void
Filterer.setup
(FragmentContext context, RecordBatch incoming, RecordBatch outgoing, TransferPair[] transfers) void
FilterTemplate2.setup
(FragmentContext context, RecordBatch incoming, RecordBatch outgoing, TransferPair[] transfers) void
FilterTemplate4.setup
(FragmentContext context, RecordBatch incoming, RecordBatch outgoing, TransferPair[] transfers) Constructors in org.apache.drill.exec.physical.impl.filter with parameters of type FragmentContextModifierConstructorDescriptionFilterRecordBatch
(Filter pop, RecordBatch incoming, FragmentContext context) RuntimeFilterRecordBatch
(RuntimeFilterPOP pop, RecordBatch incoming, FragmentContext context) -
Uses of FragmentContext in org.apache.drill.exec.physical.impl.flatten
Methods in org.apache.drill.exec.physical.impl.flatten with parameters of type FragmentContextModifier and TypeMethodDescriptionabstract void
FlattenTemplate.doSetup
(FragmentContext context, RecordBatch incoming, RecordBatch outgoing) void
Flattener.setup
(FragmentContext context, RecordBatch incoming, RecordBatch outgoing, List<TransferPair> transfers) final void
FlattenTemplate.setup
(FragmentContext context, RecordBatch incoming, RecordBatch outgoing, List<TransferPair> transfers) Constructors in org.apache.drill.exec.physical.impl.flatten with parameters of type FragmentContextModifierConstructorDescriptionFlattenRecordBatch
(FlattenPOP pop, RecordBatch incoming, FragmentContext context) -
Uses of FragmentContext in org.apache.drill.exec.physical.impl.join
Methods in org.apache.drill.exec.physical.impl.join with parameters of type FragmentContextModifier and TypeMethodDescriptionstatic void
JoinUtils.addLeastRestrictiveCasts
(LogicalExpression[] leftExpressions, VectorAccessible leftBatch, LogicalExpression[] rightExpressions, VectorAccessible rightBatch, FragmentContext context) Utility method used by joins to add implicit casts on one of the sides of the join condition in case the two expressions have different types.abstract void
JoinTemplate.doSetup
(FragmentContext context, JoinStatus status, VectorContainer outgoing) void
NestedLoopJoin.doSetup
(FragmentContext context, VectorContainer rightContainer, RecordBatch leftBatch, RecordBatch outgoing) abstract void
NestedLoopJoinTemplate.doSetup
(FragmentContext context, VectorContainer rightContainer, RecordBatch leftBatch, RecordBatch outgoing) void
JoinTemplate.setupJoin
(FragmentContext context, JoinStatus status, VectorContainer outgoing) void
JoinWorker.setupJoin
(FragmentContext context, JoinStatus status, VectorContainer outgoing) void
NestedLoopJoin.setupNestedLoopJoin
(FragmentContext context, RecordBatch left, ExpandableHyperContainer rightContainer, LinkedList<Integer> rightCounts, NestedLoopJoinBatch outgoing) void
NestedLoopJoinTemplate.setupNestedLoopJoin
(FragmentContext context, RecordBatch left, ExpandableHyperContainer rightContainer, LinkedList<Integer> rightCounts, NestedLoopJoinBatch outgoing) Method initializes necessary state and invokes the doSetup() to set the input and output value vector references.Constructors in org.apache.drill.exec.physical.impl.join with parameters of type FragmentContextModifierConstructorDescriptionAbstractHashBinaryRecordBatch
(T popConfig, FragmentContext context, RecordBatch left, RecordBatch right) The constructorHashJoinBatch
(HashJoinPOP popConfig, FragmentContext context, RecordBatch left, RecordBatch right) The constructorHashJoinHelper
(FragmentContext context, BufferAllocator allocator) LateralJoinBatch
(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 FragmentContext in org.apache.drill.exec.physical.impl.limit
Constructors in org.apache.drill.exec.physical.impl.limit with parameters of type FragmentContextModifierConstructorDescriptionLimitRecordBatch
(Limit popConfig, FragmentContext context, RecordBatch incoming) PartitionLimitRecordBatch
(PartitionLimit popConfig, FragmentContext context, RecordBatch incoming) -
Uses of FragmentContext in org.apache.drill.exec.physical.impl.materialize
Constructors in org.apache.drill.exec.physical.impl.materialize with parameters of type FragmentContextModifierConstructorDescriptionVectorRecordMaterializer
(FragmentContext context, OperatorContext oContext, RecordBatch batch) -
Uses of FragmentContext in org.apache.drill.exec.physical.impl.mergereceiver
Methods in org.apache.drill.exec.physical.impl.mergereceiver that return FragmentContextMethods in org.apache.drill.exec.physical.impl.mergereceiver with parameters of type FragmentContextModifier and TypeMethodDescriptionvoid
MergingReceiverGeneratorBase.doSetup
(FragmentContext context, VectorAccessible incoming, VectorAccessible outgoing) abstract void
MergingReceiverTemplate.doSetup
(FragmentContext context, VectorAccessible incoming, VectorAccessible outgoing) -
Uses of FragmentContext in org.apache.drill.exec.physical.impl.metadata
Constructors in org.apache.drill.exec.physical.impl.metadata with parameters of type FragmentContextModifierConstructorDescriptionprotected
MetadataControllerBatch
(MetadataControllerPOP popConfig, FragmentContext context, RecordBatch left, RecordBatch right) protected
MetadataHandlerBatch
(MetadataHandlerPOP popConfig, FragmentContext context, RecordBatch incoming) MetadataHashAggBatch
(MetadataHashAggPOP popConfig, RecordBatch incoming, FragmentContext context) MetadataStreamAggBatch
(MetadataStreamAggPOP popConfig, RecordBatch incoming, FragmentContext context) -
Uses of FragmentContext in org.apache.drill.exec.physical.impl.orderedpartitioner
Methods in org.apache.drill.exec.physical.impl.orderedpartitioner with parameters of type FragmentContextModifier and TypeMethodDescriptionabstract void
OrderedPartitionProjectorTemplate.doSetup
(FragmentContext context, VectorAccessible incoming, RecordBatch outgoing, VectorContainer partitionVectors) abstract void
SampleCopierTemplate.doSetup
(FragmentContext context, VectorAccessible incoming, VectorAccessible outgoing) abstract void
SampleSortTemplate.doSetup
(FragmentContext context, VectorContainer incoming, RecordBatch outgoing) void
OrderedPartitionProjector.setup
(FragmentContext context, VectorAccessible incoming, RecordBatch outgoing, List<TransferPair> transfers, VectorContainer partitionVectors, int partitions, SchemaPath outputField) final void
OrderedPartitionProjectorTemplate.setup
(FragmentContext context, VectorAccessible incoming, RecordBatch outgoing, List<TransferPair> transfers, VectorContainer partitionVectors, int partitions, SchemaPath outputField) void
SampleSorter.setup
(FragmentContext context, RecordBatch hyperBatch) void
SampleSortTemplate.setup
(FragmentContext context, VectorContainer sampleBatch, SelectionVector2 vector2) void
SampleCopier.setupCopier
(FragmentContext context, SelectionVector4 sv4, VectorAccessible incoming, VectorAccessible outgoing) void
SampleCopierTemplate.setupCopier
(FragmentContext context, SelectionVector4 sv4, VectorAccessible incoming, VectorAccessible outgoing) Constructors in org.apache.drill.exec.physical.impl.orderedpartitioner with parameters of type FragmentContextModifierConstructorDescriptionOrderedPartitionRecordBatch
(OrderedPartitionSender pop, RecordBatch incoming, FragmentContext context) -
Uses of FragmentContext in org.apache.drill.exec.physical.impl.partitionsender
Fields in org.apache.drill.exec.physical.impl.partitionsender declared as FragmentContextMethods in org.apache.drill.exec.physical.impl.partitionsender with parameters of type FragmentContextModifier and TypeMethodDescriptionabstract void
PartitionerTemplate.doSetup
(FragmentContext context, RecordBatch incoming, PartitionerTemplate.OutgoingRecordBatch[] outgoing) protected PartitionerTemplate.OutgoingRecordBatch
PartitionerTemplate.newOutgoingRecordBatch
(OperatorStats stats, HashPartitionSender operator, AccountingDataTunnel tunnel, FragmentContext context, BufferAllocator allocator, int oppositeMinorFragmentId) Shim method to be overridden in plain-old Java mode by the subclass to instantiate the generated inner class.Constructors in org.apache.drill.exec.physical.impl.partitionsender with parameters of type FragmentContextModifierConstructorDescriptionOutgoingRecordBatch
(OperatorStats stats, HashPartitionSender operator, AccountingDataTunnel tunnel, FragmentContext context, BufferAllocator allocator, int oppositeMinorFragmentId) -
Uses of FragmentContext in org.apache.drill.exec.physical.impl.producer
Constructors in org.apache.drill.exec.physical.impl.producer with parameters of type FragmentContextModifierConstructorDescriptionprotected
ProducerConsumerBatch
(ProducerConsumer popConfig, FragmentContext context, RecordBatch incoming) -
Uses of FragmentContext in org.apache.drill.exec.physical.impl.project
Methods in org.apache.drill.exec.physical.impl.project with parameters of type FragmentContextModifier and TypeMethodDescriptionabstract void
ProjectorTemplate.doSetup
(FragmentContext context, RecordBatch incoming, RecordBatch outgoing) void
Projector.setup
(FragmentContext context, RecordBatch incoming, RecordBatch outgoing, List<TransferPair> transfers) final void
ProjectorTemplate.setup
(FragmentContext context, RecordBatch incoming, RecordBatch outgoing, List<TransferPair> transfers) Constructors in org.apache.drill.exec.physical.impl.project with parameters of type FragmentContextModifierConstructorDescriptionProjectRecordBatch
(Project pop, RecordBatch incoming, FragmentContext context) -
Uses of FragmentContext in org.apache.drill.exec.physical.impl.protocol
Methods in org.apache.drill.exec.physical.impl.protocol that return FragmentContextModifier and TypeMethodDescriptionOperatorRecordBatch.fragmentContext()
OperatorRecordBatch.getContext()
Constructors in org.apache.drill.exec.physical.impl.protocol with parameters of type FragmentContextModifierConstructorDescriptionOperatorRecordBatch
(FragmentContext context, PhysicalOperator config, OperatorExec opExec, boolean enableSchemaBatch) -
Uses of FragmentContext in org.apache.drill.exec.physical.impl.rangepartitioner
Constructors in org.apache.drill.exec.physical.impl.rangepartitioner with parameters of type FragmentContextModifierConstructorDescriptionRangePartitionRecordBatch
(RangePartitionSender popConfig, RecordBatch incoming, FragmentContext context) -
Uses of FragmentContext in org.apache.drill.exec.physical.impl.scan.project
Methods in org.apache.drill.exec.physical.impl.scan.project with parameters of type FragmentContextModifier and TypeMethodDescriptionScanSchemaOrchestrator.ScanOrchestratorBuilder.buildScanOperator
(FragmentContext fragContext, PhysicalOperator pop) -
Uses of FragmentContext in org.apache.drill.exec.physical.impl.scan.v3
Methods in org.apache.drill.exec.physical.impl.scan.v3 with parameters of type FragmentContextModifier and TypeMethodDescriptionScanLifecycleBuilder.buildScanOperator
(FragmentContext fragContext, PhysicalOperator pop) -
Uses of FragmentContext in org.apache.drill.exec.physical.impl.setop
Constructors in org.apache.drill.exec.physical.impl.setop with parameters of type FragmentContextModifierConstructorDescriptionHashSetOpRecordBatch
(SetOp popConfig, FragmentContext context, RecordBatch left, RecordBatch right) The constructor -
Uses of FragmentContext in org.apache.drill.exec.physical.impl.sort
Methods in org.apache.drill.exec.physical.impl.sort with parameters of type FragmentContextModifier and TypeMethodDescriptionstatic Sorter
SortBatch.createNewSorter
(FragmentContext context, List<Order.Ordering> orderings, VectorAccessible batch) static Sorter
SortBatch.createNewSorter
(FragmentContext context, List<Order.Ordering> orderings, VectorAccessible batch, MappingSet mainMapping, MappingSet leftMapping, MappingSet rightMapping) abstract void
SortTemplate.doSetup
(FragmentContext context, VectorContainer incoming, RecordBatch outgoing) void
Sorter.setup
(FragmentContext context, SelectionVector4 vector4, VectorContainer hyperBatch) void
SortTemplate.setup
(FragmentContext context, SelectionVector4 vector4, VectorContainer hyperBatch) Constructors in org.apache.drill.exec.physical.impl.sort with parameters of type FragmentContextModifierConstructorDescriptionSortBatch
(Sort popConfig, FragmentContext context, RecordBatch incoming) -
Uses of FragmentContext in org.apache.drill.exec.physical.impl.spill
Constructors in org.apache.drill.exec.physical.impl.spill with parameters of type FragmentContext -
Uses of FragmentContext in org.apache.drill.exec.physical.impl.statistics
Constructors in org.apache.drill.exec.physical.impl.statistics with parameters of type FragmentContextModifierConstructorDescriptionStatisticsAggBatch
(StatisticsAggregate popConfig, RecordBatch incoming, FragmentContext context) StatisticsMergeBatch
(StatisticsMerge popConfig, RecordBatch incoming, FragmentContext context) -
Uses of FragmentContext in org.apache.drill.exec.physical.impl.svremover
Constructors in org.apache.drill.exec.physical.impl.svremover with parameters of type FragmentContextModifierConstructorDescriptionRemovingRecordBatch
(SelectionVectorRemover popConfig, FragmentContext context, RecordBatch incoming) -
Uses of FragmentContext in org.apache.drill.exec.physical.impl.TopN
Methods in org.apache.drill.exec.physical.impl.TopN with parameters of type FragmentContextModifier and TypeMethodDescriptionstatic PriorityQueue
TopNBatch.createNewPriorityQueue
(MappingSet mainMapping, MappingSet leftMapping, MappingSet rightMapping, List<Order.Ordering> orderings, VectorAccessible batch, boolean unionTypeEnabled, boolean codegenDump, int limit, BufferAllocator allocator, BatchSchema.SelectionVectorMode mode, FragmentContext context) Constructors in org.apache.drill.exec.physical.impl.TopN with parameters of type FragmentContextModifierConstructorDescriptionSimpleSV4RecordBatch
(VectorContainer container, SelectionVector4 sv4, FragmentContext context) TopNBatch
(TopN popConfig, FragmentContext context, RecordBatch incoming) -
Uses of FragmentContext in org.apache.drill.exec.physical.impl.trace
Constructors in org.apache.drill.exec.physical.impl.trace with parameters of type FragmentContextModifierConstructorDescriptionTraceRecordBatch
(Trace pop, RecordBatch incoming, FragmentContext context) -
Uses of FragmentContext in org.apache.drill.exec.physical.impl.union
Methods in org.apache.drill.exec.physical.impl.union with parameters of type FragmentContextModifier and TypeMethodDescriptionabstract void
UnionAllerTemplate.doSetup
(FragmentContext context, RecordBatch incoming, RecordBatch outgoing) void
UnionAller.setup
(FragmentContext context, RecordBatch incoming, RecordBatch outgoing, List<TransferPair> transfers) final void
UnionAllerTemplate.setup
(FragmentContext context, RecordBatch incoming, RecordBatch outgoing, List<TransferPair> transfers) Constructors in org.apache.drill.exec.physical.impl.union with parameters of type FragmentContextModifierConstructorDescriptionUnionAllRecordBatch
(UnionAll config, List<RecordBatch> children, FragmentContext context) -
Uses of FragmentContext in org.apache.drill.exec.physical.impl.unnest
Methods in org.apache.drill.exec.physical.impl.unnest with parameters of type FragmentContextModifier and TypeMethodDescriptionvoid
Unnest.setup
(FragmentContext context, RecordBatch incoming, RecordBatch outgoing, List<TransferPair> transfers) final void
UnnestImpl.setup
(FragmentContext context, RecordBatch incoming, RecordBatch outgoing, List<TransferPair> transfers) Constructors in org.apache.drill.exec.physical.impl.unnest with parameters of type FragmentContext -
Uses of FragmentContext in org.apache.drill.exec.physical.impl.unorderedreceiver
Methods in org.apache.drill.exec.physical.impl.unorderedreceiver that return FragmentContext -
Uses of FragmentContext in org.apache.drill.exec.physical.impl.unpivot
Constructors in org.apache.drill.exec.physical.impl.unpivot with parameters of type FragmentContextModifierConstructorDescriptionUnpivotMapsRecordBatch
(UnpivotMaps pop, RecordBatch incoming, FragmentContext context) -
Uses of FragmentContext in org.apache.drill.exec.physical.impl.validate
Methods in org.apache.drill.exec.physical.impl.validate that return FragmentContextMethods in org.apache.drill.exec.physical.impl.validate with parameters of type FragmentContextModifier and TypeMethodDescriptionstatic FragmentRoot
IteratorValidatorInjector.rewritePlanWithIteratorValidator
(FragmentContext context, FragmentRoot root) IteratorValidatorInjector.visitOp
(PhysicalOperator op, FragmentContext context) Traverse the physical plan and inject the IteratorValidator operator after every operator. -
Uses of FragmentContext in org.apache.drill.exec.physical.impl.window
Constructors in org.apache.drill.exec.physical.impl.window with parameters of type FragmentContextModifierConstructorDescriptionWindowFrameRecordBatch
(WindowPOP popConfig, FragmentContext context, RecordBatch incoming) -
Uses of FragmentContext in org.apache.drill.exec.physical.impl.xsort
Methods in org.apache.drill.exec.physical.impl.xsort with parameters of type FragmentContextModifier and TypeMethodDescriptionabstract void
MSortTemplate.doSetup
(FragmentContext context, VectorContainer incoming, RecordBatch outgoing) abstract void
SingleBatchSorterTemplate.doSetup
(FragmentContext context, VectorAccessible incoming, RecordBatch outgoing) void
MSorter.setup
(FragmentContext context, BufferAllocator allocator, SelectionVector4 vector4, VectorContainer hyperBatch, int outputBatchSize, int desiredBatchSize) void
MSortTemplate.setup
(FragmentContext context, BufferAllocator allocator, SelectionVector4 vector4, VectorContainer hyperBatch, int outputBatchSize, int desiredBatchSize) void
SingleBatchSorter.setup
(FragmentContext context, SelectionVector2 vector2, VectorAccessible incoming) void
SingleBatchSorterTemplate.setup
(FragmentContext context, SelectionVector2 vector2, VectorAccessible incoming) Constructors in org.apache.drill.exec.physical.impl.xsort with parameters of type FragmentContextModifierConstructorDescriptionExternalSortBatch
(ExternalSort popConfig, FragmentContext context, RecordBatch incoming) -
Uses of FragmentContext in org.apache.drill.exec.record
Fields in org.apache.drill.exec.record declared as FragmentContextMethods in org.apache.drill.exec.record that return FragmentContextModifier and TypeMethodDescriptionAbstractRecordBatch.getContext()
RecordBatch.getContext()
Gets the FragmentContext of the current query fragment.SchemalessBatch.getContext()
SimpleRecordBatch.getContext()
Methods in org.apache.drill.exec.record with parameters of type FragmentContextConstructors in org.apache.drill.exec.record with parameters of type FragmentContextModifierConstructorDescriptionprotected
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) protected
AbstractRecordBatch
(T popConfig, FragmentContext context, boolean buildSchema, OperatorContext oContext) AbstractSingleRecordBatch
(T popConfig, FragmentContext context, RecordBatch incoming) AbstractTableFunctionRecordBatch
(T popConfig, FragmentContext context) AbstractUnaryRecordBatch
(T popConfig, FragmentContext context) SimpleRecordBatch
(VectorContainer container, FragmentContext context) -
Uses of FragmentContext in org.apache.drill.exec.store
Fields in org.apache.drill.exec.store declared as FragmentContextModifier and TypeFieldDescriptionprotected final FragmentContext
CommonParquetRecordReader.fragmentContext
Constructors in org.apache.drill.exec.store with parameters of type FragmentContextModifierConstructorDescriptionCommonParquetRecordReader
(org.apache.parquet.hadoop.metadata.ParquetMetadata footer, FragmentContext fragmentContext) -
Uses of FragmentContext in org.apache.drill.exec.store.dfs.easy
Methods in org.apache.drill.exec.store.dfs.easy with parameters of type FragmentContextModifier and TypeMethodDescriptionprotected CloseableRecordBatch
EasyFormatPlugin.getReaderBatch
(FragmentContext context, EasySubScan scan) EasyFormatPlugin.getRecordReader
(FragmentContext context, DrillFileSystem dfs, FileWork fileWork, List<SchemaPath> columns, String userName) Return a record reader for the specific file format, when using the originalScanBatch
scanner.EasyFormatPlugin.getRecordWriter
(FragmentContext context, EasyWriter writer) EasyFormatPlugin.getStatisticsRecordWriter
(FragmentContext context, EasyWriter writer) EasyFormatPlugin.getWriterBatch
(FragmentContext context, RecordBatch incoming, EasyWriter writer) boolean
EasyFormatPlugin.isStatisticsRecordWriter
(FragmentContext context, EasyWriter writer) Constructors in org.apache.drill.exec.store.dfs.easy with parameters of type FragmentContextModifierConstructorDescriptionClassicScanBuilder
(FragmentContext context, EasySubScan scan, EasyFormatPlugin<? extends FormatPluginConfig> plugin) EasyFileScanBuilder
(FragmentContext context, EasySubScan scan, EasyFormatPlugin<? extends FormatPluginConfig> plugin) Constructor -
Uses of FragmentContext in org.apache.drill.exec.store.drill.plugin
Methods in org.apache.drill.exec.store.drill.plugin that return FragmentContext -
Uses of FragmentContext in org.apache.drill.exec.store.druid
Constructors in org.apache.drill.exec.store.druid with parameters of type FragmentContextModifierConstructorDescriptionDruidRecordReader
(DruidSubScan.DruidSubScanSpec subScanSpec, List<SchemaPath> projectedColumns, int maxRecordsToRead, FragmentContext context, DruidStoragePlugin plugin) -
Uses of FragmentContext in org.apache.drill.exec.store.easy.json
Methods in org.apache.drill.exec.store.easy.json with parameters of type FragmentContextModifier and TypeMethodDescriptionJSONFormatPlugin.getRecordReader
(FragmentContext context, DrillFileSystem dfs, FileWork fileWork, List<SchemaPath> columns, String userName) JSONFormatPlugin.getRecordWriter
(FragmentContext context, EasyWriter writer) JSONFormatPlugin.getStatisticsRecordWriter
(FragmentContext context, EasyWriter writer) boolean
JSONFormatPlugin.isStatisticsRecordWriter
(FragmentContext context, EasyWriter writer) Constructors in org.apache.drill.exec.store.easy.json with parameters of type FragmentContextModifierConstructorDescriptionJSONRecordReader
(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 FragmentContext in org.apache.drill.exec.store.easy.text
Methods in org.apache.drill.exec.store.easy.text with parameters of type FragmentContextModifier and TypeMethodDescriptionTextFormatPlugin.getRecordWriter
(FragmentContext context, EasyWriter writer) -
Uses of FragmentContext in org.apache.drill.exec.store.hive.readers
Constructors in org.apache.drill.exec.store.hive.readers with parameters of type FragmentContextModifierConstructorDescriptionHiveDefaultRecordReader
(HiveTableWithColumnCache table, HivePartition partition, Collection<org.apache.hadoop.mapred.InputSplit> inputSplits, List<SchemaPath> projectedColumns, FragmentContext context, org.apache.hadoop.hive.conf.HiveConf hiveConf, org.apache.hadoop.security.UserGroupInformation proxyUgi) Readers constructor called by initializer.HiveTextRecordReader
(HiveTableWithColumnCache table, HivePartition partition, Collection<org.apache.hadoop.mapred.InputSplit> inputSplits, List<SchemaPath> projectedColumns, FragmentContext context, org.apache.hadoop.hive.conf.HiveConf hiveConf, org.apache.hadoop.security.UserGroupInformation proxyUgi) Constructor matching super. -
Uses of FragmentContext in org.apache.drill.exec.store.mock
Constructors in org.apache.drill.exec.store.mock with parameters of type FragmentContextModifierConstructorDescriptionMockRecordReader
(FragmentContext context, MockTableDef.MockScanEntry config) -
Uses of FragmentContext in org.apache.drill.exec.store.mongo
Constructors in org.apache.drill.exec.store.mongo with parameters of type FragmentContextModifierConstructorDescriptionMongoRecordReader
(BaseMongoSubScanSpec subScanSpec, List<SchemaPath> projectedColumns, FragmentContext context, MongoStoragePlugin plugin) -
Uses of FragmentContext in org.apache.drill.exec.store.parquet
Methods in org.apache.drill.exec.store.parquet with parameters of type FragmentContextModifier and TypeMethodDescriptionstatic RowsMatch
FilterEvaluatorUtils.evalFilter
(LogicalExpression expr, MetadataBase.ParquetTableMetadataBase footer, int rowGroupIndex, OptionManager options, FragmentContext fragmentContext) ParquetFormatPlugin.getRecordWriter
(FragmentContext context, ParquetWriter writer) ParquetFormatPlugin.getWriterBatch
(FragmentContext context, RecordBatch incoming, ParquetWriter writer) Constructors in org.apache.drill.exec.store.parquet with parameters of type FragmentContext -
Uses of FragmentContext in org.apache.drill.exec.store.parquet.columnreaders
Methods in org.apache.drill.exec.store.parquet.columnreaders that return FragmentContextConstructors in org.apache.drill.exec.store.parquet.columnreaders with parameters of type FragmentContextModifierConstructorDescriptionParquetRecordReader
(FragmentContext fragmentContext, long numRecordsToRead, org.apache.hadoop.fs.Path path, int rowGroupIndex, org.apache.hadoop.fs.FileSystem fs, org.apache.parquet.compression.CompressionCodecFactory codecFactory, org.apache.parquet.hadoop.metadata.ParquetMetadata footer, List<SchemaPath> columns, ParquetReaderUtility.DateCorruptionStatus dateCorruptionStatus) ParquetRecordReader
(FragmentContext fragmentContext, org.apache.hadoop.fs.Path path, int rowGroupIndex, long numRecordsToRead, org.apache.hadoop.fs.FileSystem fs, org.apache.parquet.compression.CompressionCodecFactory codecFactory, org.apache.parquet.hadoop.metadata.ParquetMetadata footer, List<SchemaPath> columns, ParquetReaderUtility.DateCorruptionStatus dateCorruptionStatus) ParquetRecordReader
(FragmentContext fragmentContext, org.apache.hadoop.fs.Path path, int rowGroupIndex, org.apache.hadoop.fs.FileSystem fs, org.apache.parquet.compression.CompressionCodecFactory codecFactory, org.apache.parquet.hadoop.metadata.ParquetMetadata footer, List<SchemaPath> columns, ParquetReaderUtility.DateCorruptionStatus dateCorruptionStatus) -
Uses of FragmentContext in org.apache.drill.exec.store.parquet2
Constructors in org.apache.drill.exec.store.parquet2 with parameters of type FragmentContextModifierConstructorDescriptionDrillParquetReader
(FragmentContext fragmentContext, org.apache.parquet.hadoop.metadata.ParquetMetadata footer, RowGroupReadEntry entry, List<SchemaPath> columns, DrillFileSystem fileSystem, ParquetReaderUtility.DateCorruptionStatus containsCorruptedDates, long recordsToRead) -
Uses of FragmentContext in org.apache.drill.exec.store.sys
Constructors in org.apache.drill.exec.store.sys with parameters of type FragmentContextModifierConstructorDescriptionAliasesIterator
(FragmentContext context, AliasTarget aliasTarget, int maxRecords) ExtendedOptionIterator
(FragmentContext context, boolean internal) OptionIterator
(FragmentContext context, org.apache.drill.exec.store.sys.OptionIterator.Mode mode) -
Uses of FragmentContext in org.apache.drill.exec.util
Methods in org.apache.drill.exec.util with parameters of type FragmentContextModifier and TypeMethodDescriptionstatic String
Utilities.getFileNameForQueryFragment
(FragmentContext context, String location, String tag) -
Uses of FragmentContext in org.apache.drill.exec.util.record
Constructors in org.apache.drill.exec.util.record with parameters of type FragmentContextModifierConstructorDescriptionRecordBatchStatsContext
(FragmentContext context, OperatorContext oContext) -
Uses of FragmentContext in org.apache.drill.exec.work.batch
Fields in org.apache.drill.exec.work.batch declared as FragmentContextMethods in org.apache.drill.exec.work.batch with parameters of type FragmentContextModifier and TypeMethodDescriptionvoid
BaseRawBatchBuffer.kill
(FragmentContext context) void
SpoolingRawBatchBuffer.kill
(FragmentContext context) Constructors in org.apache.drill.exec.work.batch with parameters of type FragmentContextModifierConstructorDescriptionAbstractDataCollector
(AtomicInteger parentAccounter, int numBuffers, BitControl.Collector collector, int bufferCapacity, FragmentContext context) BaseRawBatchBuffer
(FragmentContext context, int fragmentCount, boolean enableDynamicFC) IncomingBuffers
(BitControl.PlanFragment fragment, FragmentContext context) MergingCollector
(AtomicInteger parentAccounter, BitControl.Collector collector, FragmentContext context) PartitionedCollector
(AtomicInteger parentAccounter, BitControl.Collector collector, FragmentContext context) SpoolingRawBatchBuffer
(FragmentContext context, int fragmentCount, int oppositeId, int bufferIndex, boolean enableDynamicFC) UnlimitedRawBatchBuffer
(FragmentContext context, int fragmentCount, boolean enableDynamicFC) -
Uses of FragmentContext in org.apache.drill.exec.work.fragment
Methods in org.apache.drill.exec.work.fragment that return FragmentContextModifier and TypeMethodDescriptionAbstractFragmentManager.getFragmentContext()
FragmentManager.getFragmentContext()