Uses of Interface
org.apache.drill.exec.ops.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
ModifierConstructorDescriptionValueVectorHashHelper
(RecordBatch recordBatch, FragmentContext context) -
Uses of FragmentContext in org.apache.drill.exec.ops
Modifier 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
.Modifier 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.Modifier and TypeMethodDescriptionBaseOperatorContext.getFragmentContext()
OperatorContext.getFragmentContext()
ModifierConstructorDescriptionBaseOperatorContext
(FragmentContext context, BufferAllocator allocator, PhysicalOperator popConfig) -
Uses of FragmentContext in org.apache.drill.exec.physical.base
Modifier 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
Modifier 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.ModifierConstructorDescriptionInsertWriterRecordBatch
(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
Modifier 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) ModifierConstructorDescriptionHashAggBatch
(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
Modifier 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) ModifierConstructorDescriptionChainedHashTable
(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
Modifier and TypeMethodDescriptionFilterRecordBatch.getContext()
RuntimeFilterRecordBatch.getContext()
Modifier 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) ModifierConstructorDescriptionFilterRecordBatch
(Filter pop, RecordBatch incoming, FragmentContext context) RuntimeFilterRecordBatch
(RuntimeFilterPOP pop, RecordBatch incoming, FragmentContext context) -
Uses of FragmentContext in org.apache.drill.exec.physical.impl.flatten
Modifier 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) ModifierConstructorDescriptionFlattenRecordBatch
(FlattenPOP pop, RecordBatch incoming, FragmentContext context) -
Uses of FragmentContext in org.apache.drill.exec.physical.impl.join
Modifier 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.ModifierConstructorDescriptionAbstractHashBinaryRecordBatch
(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
ModifierConstructorDescriptionLimitRecordBatch
(Limit popConfig, FragmentContext context, RecordBatch incoming) PartitionLimitRecordBatch
(PartitionLimit popConfig, FragmentContext context, RecordBatch incoming) -
Uses of FragmentContext in org.apache.drill.exec.physical.impl.materialize
ModifierConstructorDescriptionVectorRecordMaterializer
(FragmentContext context, OperatorContext oContext, RecordBatch batch) -
Uses of FragmentContext in org.apache.drill.exec.physical.impl.mergereceiver
Modifier 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
ModifierConstructorDescriptionprotected
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
Modifier 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) ModifierConstructorDescriptionOrderedPartitionRecordBatch
(OrderedPartitionSender pop, RecordBatch incoming, FragmentContext context) -
Uses of FragmentContext in org.apache.drill.exec.physical.impl.partitionsender
Modifier 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.ModifierConstructorDescriptionOutgoingRecordBatch
(OperatorStats stats, HashPartitionSender operator, AccountingDataTunnel tunnel, FragmentContext context, BufferAllocator allocator, int oppositeMinorFragmentId) -
Uses of FragmentContext in org.apache.drill.exec.physical.impl.producer
ModifierConstructorDescriptionprotected
ProducerConsumerBatch
(ProducerConsumer popConfig, FragmentContext context, RecordBatch incoming) -
Uses of FragmentContext in org.apache.drill.exec.physical.impl.project
Modifier 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) ModifierConstructorDescriptionProjectRecordBatch
(Project pop, RecordBatch incoming, FragmentContext context) -
Uses of FragmentContext in org.apache.drill.exec.physical.impl.protocol
Modifier and TypeMethodDescriptionOperatorRecordBatch.fragmentContext()
OperatorRecordBatch.getContext()
ModifierConstructorDescriptionOperatorRecordBatch
(FragmentContext context, PhysicalOperator config, OperatorExec opExec, boolean enableSchemaBatch) -
Uses of FragmentContext in org.apache.drill.exec.physical.impl.rangepartitioner
ModifierConstructorDescriptionRangePartitionRecordBatch
(RangePartitionSender popConfig, RecordBatch incoming, FragmentContext context) -
Uses of FragmentContext in org.apache.drill.exec.physical.impl.scan.project
Modifier and TypeMethodDescriptionScanSchemaOrchestrator.ScanOrchestratorBuilder.buildScanOperator
(FragmentContext fragContext, PhysicalOperator pop) -
Uses of FragmentContext in org.apache.drill.exec.physical.impl.scan.v3
Modifier and TypeMethodDescriptionScanLifecycleBuilder.buildScanOperator
(FragmentContext fragContext, PhysicalOperator pop) -
Uses of FragmentContext in org.apache.drill.exec.physical.impl.setop
ModifierConstructorDescriptionHashSetOpRecordBatch
(SetOp popConfig, FragmentContext context, RecordBatch left, RecordBatch right) The constructor -
Uses of FragmentContext in org.apache.drill.exec.physical.impl.sort
Modifier 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) ModifierConstructorDescriptionSortBatch
(Sort popConfig, FragmentContext context, RecordBatch incoming) -
Uses of FragmentContext in org.apache.drill.exec.physical.impl.spill
-
Uses of FragmentContext in org.apache.drill.exec.physical.impl.statistics
ModifierConstructorDescriptionStatisticsAggBatch
(StatisticsAggregate popConfig, RecordBatch incoming, FragmentContext context) StatisticsMergeBatch
(StatisticsMerge popConfig, RecordBatch incoming, FragmentContext context) -
Uses of FragmentContext in org.apache.drill.exec.physical.impl.svremover
ModifierConstructorDescriptionRemovingRecordBatch
(SelectionVectorRemover popConfig, FragmentContext context, RecordBatch incoming) -
Uses of FragmentContext in org.apache.drill.exec.physical.impl.TopN
Modifier 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) ModifierConstructorDescriptionSimpleSV4RecordBatch
(VectorContainer container, SelectionVector4 sv4, FragmentContext context) TopNBatch
(TopN popConfig, FragmentContext context, RecordBatch incoming) -
Uses of FragmentContext in org.apache.drill.exec.physical.impl.trace
ModifierConstructorDescriptionTraceRecordBatch
(Trace pop, RecordBatch incoming, FragmentContext context) -
Uses of FragmentContext in org.apache.drill.exec.physical.impl.union
Modifier 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) ModifierConstructorDescriptionUnionAllRecordBatch
(UnionAll config, List<RecordBatch> children, FragmentContext context) -
Uses of FragmentContext in org.apache.drill.exec.physical.impl.unnest
Modifier 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) -
Uses of FragmentContext in org.apache.drill.exec.physical.impl.unorderedreceiver
-
Uses of FragmentContext in org.apache.drill.exec.physical.impl.unpivot
ModifierConstructorDescriptionUnpivotMapsRecordBatch
(UnpivotMaps pop, RecordBatch incoming, FragmentContext context) -
Uses of FragmentContext in org.apache.drill.exec.physical.impl.validate
Modifier 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
ModifierConstructorDescriptionWindowFrameRecordBatch
(WindowPOP popConfig, FragmentContext context, RecordBatch incoming) -
Uses of FragmentContext in org.apache.drill.exec.physical.impl.xsort
Modifier 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) ModifierConstructorDescriptionExternalSortBatch
(ExternalSort popConfig, FragmentContext context, RecordBatch incoming) -
Uses of FragmentContext in org.apache.drill.exec.record
Modifier and TypeMethodDescriptionAbstractRecordBatch.getContext()
RecordBatch.getContext()
Gets the FragmentContext of the current query fragment.SchemalessBatch.getContext()
SimpleRecordBatch.getContext()
ModifierConstructorDescriptionprotected
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
Modifier and TypeFieldDescriptionprotected final FragmentContext
CommonParquetRecordReader.fragmentContext
ModifierConstructorDescriptionCommonParquetRecordReader
(org.apache.parquet.hadoop.metadata.ParquetMetadata footer, FragmentContext fragmentContext) -
Uses of FragmentContext in org.apache.drill.exec.store.dfs.easy
Modifier 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) ModifierConstructorDescriptionClassicScanBuilder
(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
-
Uses of FragmentContext in org.apache.drill.exec.store.druid
ModifierConstructorDescriptionDruidRecordReader
(DruidSubScan.DruidSubScanSpec subScanSpec, List<SchemaPath> projectedColumns, int maxRecordsToRead, FragmentContext context, DruidStoragePlugin plugin) -
Uses of FragmentContext in org.apache.drill.exec.store.easy.json
Modifier 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) ModifierConstructorDescriptionJSONRecordReader
(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
Modifier and TypeMethodDescriptionTextFormatPlugin.getRecordWriter
(FragmentContext context, EasyWriter writer) -
Uses of FragmentContext in org.apache.drill.exec.store.hive.readers
ModifierConstructorDescriptionHiveDefaultRecordReader
(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
ModifierConstructorDescriptionMockRecordReader
(FragmentContext context, MockTableDef.MockScanEntry config) -
Uses of FragmentContext in org.apache.drill.exec.store.mongo
ModifierConstructorDescriptionMongoRecordReader
(BaseMongoSubScanSpec subScanSpec, List<SchemaPath> projectedColumns, FragmentContext context, MongoStoragePlugin plugin) -
Uses of FragmentContext in org.apache.drill.exec.store.parquet
Modifier 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) -
Uses of FragmentContext in org.apache.drill.exec.store.parquet.columnreaders
ModifierConstructorDescriptionParquetRecordReader
(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
ModifierConstructorDescriptionDrillParquetReader
(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
ModifierConstructorDescriptionAliasesIterator
(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
Modifier and TypeMethodDescriptionstatic String
Utilities.getFileNameForQueryFragment
(FragmentContext context, String location, String tag) -
Uses of FragmentContext in org.apache.drill.exec.util.record
ModifierConstructorDescriptionRecordBatchStatsContext
(FragmentContext context, OperatorContext oContext) -
Uses of FragmentContext in org.apache.drill.exec.work.batch
Modifier and TypeMethodDescriptionvoid
BaseRawBatchBuffer.kill
(FragmentContext context) void
SpoolingRawBatchBuffer.kill
(FragmentContext context) ModifierConstructorDescriptionAbstractDataCollector
(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
Modifier and TypeMethodDescriptionAbstractFragmentManager.getFragmentContext()
FragmentManager.getFragmentContext()