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.implConstructors 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.opsSubinterfaces of FragmentContext in org.apache.drill.exec.opsModifier and TypeInterfaceDescriptioninterfaceThis provides the resources required by an exchange operator.interfaceThe context that is used by a Drillbit in classes like theFragmentExecutor.interfaceProvides services needed by theFragmentExecutor.Classes in org.apache.drill.exec.ops that implement FragmentContextModifier and TypeClassDescriptionclassCommon implementation for both the test and production versions of the fragment context.classThis 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.baseMethods in org.apache.drill.exec.physical.base with parameters of type FragmentContextModifier and TypeMethodDescriptionstatic LogicalExpressionPhysicalOperatorUtil.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.implMethods in org.apache.drill.exec.physical.impl that return FragmentContextMethods in org.apache.drill.exec.physical.impl with parameters of type FragmentContextModifier and TypeMethodDescriptionstatic PhysicalOperatorTraceInjector.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.aggregateFields 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 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) 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.commonFields 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 voidCodeGenMemberInjector.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.voidHashTable.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.voidHashTableTemplate.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.filterMethods 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 voidFilterTemplate2.doSetup(FragmentContext context, RecordBatch incoming, RecordBatch outgoing) abstract voidFilterTemplate4.doSetup(FragmentContext context, RecordBatch incoming, RecordBatch outgoing) voidFilterer.setup(FragmentContext context, RecordBatch incoming, RecordBatch outgoing, TransferPair[] transfers) voidFilterTemplate2.setup(FragmentContext context, RecordBatch incoming, RecordBatch outgoing, TransferPair[] transfers) voidFilterTemplate4.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.flattenMethods in org.apache.drill.exec.physical.impl.flatten with parameters of type FragmentContextModifier and TypeMethodDescriptionabstract voidFlattenTemplate.doSetup(FragmentContext context, RecordBatch incoming, RecordBatch outgoing) voidFlattener.setup(FragmentContext context, RecordBatch incoming, RecordBatch outgoing, List<TransferPair> transfers) final voidFlattenTemplate.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.joinMethods in org.apache.drill.exec.physical.impl.join with parameters of type FragmentContextModifier and TypeMethodDescriptionstatic voidJoinUtils.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 voidJoinTemplate.doSetup(FragmentContext context, JoinStatus status, VectorContainer outgoing) voidNestedLoopJoin.doSetup(FragmentContext context, VectorContainer rightContainer, RecordBatch leftBatch, RecordBatch outgoing) abstract voidNestedLoopJoinTemplate.doSetup(FragmentContext context, VectorContainer rightContainer, RecordBatch leftBatch, RecordBatch outgoing) voidJoinTemplate.setupJoin(FragmentContext context, JoinStatus status, VectorContainer outgoing) voidJoinWorker.setupJoin(FragmentContext context, JoinStatus status, VectorContainer outgoing) voidNestedLoopJoin.setupNestedLoopJoin(FragmentContext context, RecordBatch left, RecordBatch.IterOutcome leftOutcome, ExpandableHyperContainer rightContainer, LinkedList<Integer> rightCounts, NestedLoopJoinBatch outgoing) voidNestedLoopJoinTemplate.setupNestedLoopJoin(FragmentContext context, RecordBatch left, RecordBatch.IterOutcome leftOutcome, 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) protectedMergeJoinBatch(MergeJoinPOP popConfig, FragmentContext context, RecordBatch left, RecordBatch right) protectedNestedLoopJoinBatch(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.limitConstructors 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.materializeConstructors 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.mergereceiverMethods 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 TypeMethodDescriptionvoidMergingReceiverGeneratorBase.doSetup(FragmentContext context, VectorAccessible incoming, VectorAccessible outgoing) abstract voidMergingReceiverTemplate.doSetup(FragmentContext context, VectorAccessible incoming, VectorAccessible outgoing) 
- 
Uses of FragmentContext in org.apache.drill.exec.physical.impl.metadataConstructors in org.apache.drill.exec.physical.impl.metadata with parameters of type FragmentContextModifierConstructorDescriptionprotectedMetadataControllerBatch(MetadataControllerPOP popConfig, FragmentContext context, RecordBatch left, RecordBatch right) protectedMetadataHandlerBatch(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.orderedpartitionerMethods in org.apache.drill.exec.physical.impl.orderedpartitioner with parameters of type FragmentContextModifier and TypeMethodDescriptionabstract voidOrderedPartitionProjectorTemplate.doSetup(FragmentContext context, VectorAccessible incoming, RecordBatch outgoing, VectorContainer partitionVectors) abstract voidSampleCopierTemplate.doSetup(FragmentContext context, VectorAccessible incoming, VectorAccessible outgoing) abstract voidSampleSortTemplate.doSetup(FragmentContext context, VectorContainer incoming, RecordBatch outgoing) voidOrderedPartitionProjector.setup(FragmentContext context, VectorAccessible incoming, RecordBatch outgoing, List<TransferPair> transfers, VectorContainer partitionVectors, int partitions, SchemaPath outputField) final voidOrderedPartitionProjectorTemplate.setup(FragmentContext context, VectorAccessible incoming, RecordBatch outgoing, List<TransferPair> transfers, VectorContainer partitionVectors, int partitions, SchemaPath outputField) voidSampleSorter.setup(FragmentContext context, RecordBatch hyperBatch) voidSampleSortTemplate.setup(FragmentContext context, VectorContainer sampleBatch, SelectionVector2 vector2) voidSampleCopier.setupCopier(FragmentContext context, SelectionVector4 sv4, VectorAccessible incoming, VectorAccessible outgoing) voidSampleCopierTemplate.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.partitionsenderFields 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 voidPartitionerTemplate.doSetup(FragmentContext context, RecordBatch incoming, PartitionerTemplate.OutgoingRecordBatch[] outgoing) protected PartitionerTemplate.OutgoingRecordBatchPartitionerTemplate.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.producerConstructors in org.apache.drill.exec.physical.impl.producer with parameters of type FragmentContextModifierConstructorDescriptionprotectedProducerConsumerBatch(ProducerConsumer popConfig, FragmentContext context, RecordBatch incoming) 
- 
Uses of FragmentContext in org.apache.drill.exec.physical.impl.projectMethods in org.apache.drill.exec.physical.impl.project with parameters of type FragmentContextModifier and TypeMethodDescriptionabstract voidProjectorTemplate.doSetup(FragmentContext context, RecordBatch incoming, RecordBatch outgoing) voidProjector.setup(FragmentContext context, RecordBatch incoming, RecordBatch outgoing, List<TransferPair> transfers) final voidProjectorTemplate.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.protocolMethods 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.rangepartitionerConstructors 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.projectMethods 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.v3Methods 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.setopConstructors 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.sortMethods in org.apache.drill.exec.physical.impl.sort with parameters of type FragmentContextModifier and TypeMethodDescriptionstatic SorterSortBatch.createNewSorter(FragmentContext context, List<Order.Ordering> orderings, VectorAccessible batch) static SorterSortBatch.createNewSorter(FragmentContext context, List<Order.Ordering> orderings, VectorAccessible batch, MappingSet mainMapping, MappingSet leftMapping, MappingSet rightMapping) abstract voidSortTemplate.doSetup(FragmentContext context, VectorContainer incoming, RecordBatch outgoing) voidSorter.setup(FragmentContext context, SelectionVector4 vector4, VectorContainer hyperBatch) voidSortTemplate.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.spillConstructors in org.apache.drill.exec.physical.impl.spill with parameters of type FragmentContext
- 
Uses of FragmentContext in org.apache.drill.exec.physical.impl.statisticsConstructors 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.svremoverConstructors 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.TopNMethods in org.apache.drill.exec.physical.impl.TopN with parameters of type FragmentContextModifier and TypeMethodDescriptionstatic PriorityQueueTopNBatch.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.traceConstructors 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.unionMethods in org.apache.drill.exec.physical.impl.union with parameters of type FragmentContextModifier and TypeMethodDescriptionabstract voidUnionAllerTemplate.doSetup(FragmentContext context, RecordBatch incoming, RecordBatch outgoing) voidUnionAller.setup(FragmentContext context, RecordBatch incoming, RecordBatch outgoing, List<TransferPair> transfers) final voidUnionAllerTemplate.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.unnestMethods in org.apache.drill.exec.physical.impl.unnest with parameters of type FragmentContextModifier and TypeMethodDescriptionvoidUnnest.setup(FragmentContext context, RecordBatch incoming, RecordBatch outgoing, List<TransferPair> transfers) final voidUnnestImpl.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.unorderedreceiverMethods in org.apache.drill.exec.physical.impl.unorderedreceiver that return FragmentContext
- 
Uses of FragmentContext in org.apache.drill.exec.physical.impl.unpivotConstructors 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.validateMethods 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 FragmentRootIteratorValidatorInjector.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.windowConstructors 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.xsortMethods in org.apache.drill.exec.physical.impl.xsort with parameters of type FragmentContextModifier and TypeMethodDescriptionabstract voidMSortTemplate.doSetup(FragmentContext context, VectorContainer incoming, RecordBatch outgoing) abstract voidSingleBatchSorterTemplate.doSetup(FragmentContext context, VectorAccessible incoming, RecordBatch outgoing) voidMSorter.setup(FragmentContext context, BufferAllocator allocator, SelectionVector4 vector4, VectorContainer hyperBatch, int outputBatchSize, int desiredBatchSize) voidMSortTemplate.setup(FragmentContext context, BufferAllocator allocator, SelectionVector4 vector4, VectorContainer hyperBatch, int outputBatchSize, int desiredBatchSize) voidSingleBatchSorter.setup(FragmentContext context, SelectionVector2 vector2, VectorAccessible incoming) voidSingleBatchSorterTemplate.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.recordFields 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 FragmentContextModifierConstructorDescriptionprotectedAbstractBinaryRecordBatch(T popConfig, FragmentContext context, boolean buildSchema, RecordBatch left, RecordBatch right) protectedAbstractBinaryRecordBatch(T popConfig, FragmentContext context, RecordBatch left, RecordBatch right) protectedAbstractRecordBatch(T popConfig, FragmentContext context) protectedAbstractRecordBatch(T popConfig, FragmentContext context, boolean buildSchema) protectedAbstractRecordBatch(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.storeFields in org.apache.drill.exec.store declared as FragmentContextModifier and TypeFieldDescriptionprotected final FragmentContextCommonParquetRecordReader.fragmentContextConstructors 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.easyMethods in org.apache.drill.exec.store.dfs.easy with parameters of type FragmentContextModifier and TypeMethodDescriptionprotected CloseableRecordBatchEasyFormatPlugin.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 originalScanBatchscanner.EasyFormatPlugin.getRecordWriter(FragmentContext context, EasyWriter writer) EasyFormatPlugin.getStatisticsRecordWriter(FragmentContext context, EasyWriter writer) EasyFormatPlugin.getWriterBatch(FragmentContext context, RecordBatch incoming, EasyWriter writer) booleanEasyFormatPlugin.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.pluginMethods in org.apache.drill.exec.store.drill.plugin that return FragmentContext
- 
Uses of FragmentContext in org.apache.drill.exec.store.druidConstructors 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.jsonMethods 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) booleanJSONFormatPlugin.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.textMethods 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.readersConstructors 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.mockConstructors 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.mongoConstructors 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.parquetMethods in org.apache.drill.exec.store.parquet with parameters of type FragmentContextModifier and TypeMethodDescriptionstatic RowsMatchFilterEvaluatorUtils.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.columnreadersMethods 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.parquet2Constructors 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.sysConstructors 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.utilMethods in org.apache.drill.exec.util with parameters of type FragmentContextModifier and TypeMethodDescriptionstatic StringUtilities.getFileNameForQueryFragment(FragmentContext context, String location, String tag) 
- 
Uses of FragmentContext in org.apache.drill.exec.util.recordConstructors 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.batchFields in org.apache.drill.exec.work.batch declared as FragmentContextMethods in org.apache.drill.exec.work.batch with parameters of type FragmentContextModifier and TypeMethodDescriptionvoidBaseRawBatchBuffer.kill(FragmentContext context) voidSpoolingRawBatchBuffer.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.fragmentMethods in org.apache.drill.exec.work.fragment that return FragmentContextModifier and TypeMethodDescriptionAbstractFragmentManager.getFragmentContext()FragmentManager.getFragmentContext()