Constructor and Description |
---|
ValueVectorHashHelper(RecordBatch recordBatch,
FragmentContext context) |
Modifier and Type | Interface and Description |
---|---|
interface |
ExchangeFragmentContext
This provides the resources required by an exchange operator.
|
interface |
ExecutorFragmentContext
The context that is used by a Drillbit in classes like the
FragmentExecutor . |
interface |
RootFragmentContext
Provides services needed by the
FragmentExecutor . |
Modifier and Type | Class and Description |
---|---|
class |
BaseFragmentContext
Common implementation for both the test and production versions
of the fragment context.
|
class |
FragmentContextImpl
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 Type | Field and Description |
---|---|
protected FragmentContext |
BaseOperatorContext.context |
Modifier and Type | Method and Description |
---|---|
FragmentContext |
BaseOperatorContext.getFragmentContext() |
FragmentContext |
OperatorContext.getFragmentContext() |
Constructor and Description |
---|
BaseOperatorContext(FragmentContext context,
BufferAllocator allocator,
PhysicalOperator popConfig) |
Modifier and Type | Method and Description |
---|---|
static LogicalExpression |
PhysicalOperatorUtil.materializeExpression(LogicalExpression expr,
VectorAccessible incoming,
FragmentContext context)
Helper method to materialize the given logical expression using the
ExpressionTreeMaterializer . |
Modifier and Type | Method and Description |
---|---|
FragmentContext |
ScanBatch.getContext() |
Modifier and Type | Method and Description |
---|---|
static PhysicalOperator |
TraceInjector.getExec(FragmentContext context,
FragmentRoot root) |
PhysicalOperator |
TraceInjector.visitOp(PhysicalOperator op,
FragmentContext context)
Traverse the physical plan and inject the trace operator after
every operator.
|
Constructor and Description |
---|
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) |
Modifier and Type | Field and Description |
---|---|
protected FragmentContext |
HashAggTemplate.context |
Modifier and Type | Method and Description |
---|---|
FragmentContext |
InternalBatch.getContext() |
FragmentContext |
SpilledRecordBatch.getContext() |
Modifier and Type | Method and Description |
---|---|
void |
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) |
Constructor and Description |
---|
HashAggBatch(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) |
Modifier and Type | Field and Description |
---|---|
protected FragmentContext |
HashTableTemplate.context |
Constructor and Description |
---|
ChainedHashTable(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) |
Modifier and Type | Method and Description |
---|---|
FragmentContext |
FilterRecordBatch.getContext() |
FragmentContext |
RuntimeFilterRecordBatch.getContext() |
Modifier and Type | Method and Description |
---|---|
abstract 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) |
Constructor and Description |
---|
FilterRecordBatch(Filter pop,
RecordBatch incoming,
FragmentContext context) |
RuntimeFilterRecordBatch(RuntimeFilterPOP pop,
RecordBatch incoming,
FragmentContext context) |
Modifier and Type | Method and Description |
---|---|
abstract void |
FlattenTemplate.doSetup(FragmentContext context,
RecordBatch incoming,
RecordBatch outgoing) |
void |
Flattener.setup(FragmentContext context,
RecordBatch incoming,
RecordBatch outgoing,
List<TransferPair> transfers) |
void |
FlattenTemplate.setup(FragmentContext context,
RecordBatch incoming,
RecordBatch outgoing,
List<TransferPair> transfers) |
Constructor and Description |
---|
FlattenRecordBatch(FlattenPOP pop,
RecordBatch incoming,
FragmentContext context) |
Modifier and Type | Method and Description |
---|---|
static 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.
|
Constructor and Description |
---|
HashJoinBatch(HashJoinPOP popConfig,
FragmentContext context,
RecordBatch left,
RecordBatch right)
The constructor
|
HashJoinHelper(FragmentContext context,
BufferAllocator allocator) |
LateralJoinBatch(LateralJoinPOP popConfig,
FragmentContext context,
RecordBatch left,
RecordBatch right) |
MergeJoinBatch(MergeJoinPOP popConfig,
FragmentContext context,
RecordBatch left,
RecordBatch right) |
NestedLoopJoinBatch(NestedLoopJoinPOP popConfig,
FragmentContext context,
RecordBatch left,
RecordBatch right) |
RowKeyJoinBatch(RowKeyJoinPOP config,
FragmentContext context,
RecordBatch left,
RecordBatch right) |
Constructor and Description |
---|
LimitRecordBatch(Limit popConfig,
FragmentContext context,
RecordBatch incoming) |
PartitionLimitRecordBatch(PartitionLimit popConfig,
FragmentContext context,
RecordBatch incoming) |
Constructor and Description |
---|
VectorRecordMaterializer(FragmentContext context,
OperatorContext oContext,
RecordBatch batch) |
Modifier and Type | Method and Description |
---|---|
FragmentContext |
MergingRecordBatch.getContext() |
Modifier and Type | Method and Description |
---|---|
void |
MergingReceiverGeneratorBase.doSetup(FragmentContext context,
VectorAccessible incoming,
VectorAccessible outgoing) |
abstract void |
MergingReceiverTemplate.doSetup(FragmentContext context,
VectorAccessible incoming,
VectorAccessible outgoing) |
Constructor and Description |
---|
MetadataControllerBatch(MetadataControllerPOP popConfig,
FragmentContext context,
RecordBatch left,
RecordBatch right) |
MetadataHandlerBatch(MetadataHandlerPOP popConfig,
FragmentContext context,
RecordBatch incoming) |
MetadataHashAggBatch(MetadataHashAggPOP popConfig,
RecordBatch incoming,
FragmentContext context) |
MetadataStreamAggBatch(MetadataStreamAggPOP popConfig,
RecordBatch incoming,
FragmentContext context) |
Modifier and Type | Method and Description |
---|---|
abstract 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 |
SampleSorter.setup(FragmentContext context,
RecordBatch hyperBatch) |
void |
OrderedPartitionProjector.setup(FragmentContext context,
VectorAccessible incoming,
RecordBatch outgoing,
List<TransferPair> transfers,
VectorContainer partitionVectors,
int partitions,
SchemaPath outputField) |
void |
OrderedPartitionProjectorTemplate.setup(FragmentContext context,
VectorAccessible incoming,
RecordBatch outgoing,
List<TransferPair> transfers,
VectorContainer partitionVectors,
int partitions,
SchemaPath outputField) |
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) |
Constructor and Description |
---|
OrderedPartitionRecordBatch(OrderedPartitionSender pop,
RecordBatch incoming,
FragmentContext context) |
Modifier and Type | Field and Description |
---|---|
protected FragmentContext |
PartitionerTemplate.context |
Modifier and Type | Method and Description |
---|---|
abstract 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.
|
Constructor and Description |
---|
OutgoingRecordBatch(OperatorStats stats,
HashPartitionSender operator,
AccountingDataTunnel tunnel,
FragmentContext context,
BufferAllocator allocator,
int oppositeMinorFragmentId) |
Constructor and Description |
---|
ProducerConsumerBatch(ProducerConsumer popConfig,
FragmentContext context,
RecordBatch incoming) |
Modifier and Type | Method and Description |
---|---|
abstract void |
ProjectorTemplate.doSetup(FragmentContext context,
RecordBatch incoming,
RecordBatch outgoing) |
void |
Projector.setup(FragmentContext context,
RecordBatch incoming,
RecordBatch outgoing,
List<TransferPair> transfers) |
void |
ProjectorTemplate.setup(FragmentContext context,
RecordBatch incoming,
RecordBatch outgoing,
List<TransferPair> transfers) |
Constructor and Description |
---|
ProjectRecordBatch(Project pop,
RecordBatch incoming,
FragmentContext context) |
Modifier and Type | Method and Description |
---|---|
FragmentContext |
OperatorRecordBatch.fragmentContext() |
FragmentContext |
OperatorRecordBatch.getContext() |
Constructor and Description |
---|
OperatorRecordBatch(FragmentContext context,
PhysicalOperator config,
OperatorExec opExec,
boolean enableSchemaBatch) |
Constructor and Description |
---|
RangePartitionRecordBatch(RangePartitionSender popConfig,
RecordBatch incoming,
FragmentContext context) |
Modifier and Type | Method and Description |
---|---|
OperatorRecordBatch |
ScanSchemaOrchestrator.ScanOrchestratorBuilder.buildScanOperator(FragmentContext fragContext,
PhysicalOperator pop) |
Modifier and Type | Method and Description |
---|---|
OperatorRecordBatch |
ScanLifecycleBuilder.buildScanOperator(FragmentContext fragContext,
PhysicalOperator pop) |
Modifier and Type | Method and Description |
---|---|
static 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) |
Constructor and Description |
---|
SortBatch(Sort popConfig,
FragmentContext context,
RecordBatch incoming) |
Constructor and Description |
---|
SpillSet(FragmentContext context,
PhysicalOperator popConfig) |
Constructor and Description |
---|
StatisticsAggBatch(StatisticsAggregate popConfig,
RecordBatch incoming,
FragmentContext context) |
StatisticsMergeBatch(StatisticsMerge popConfig,
RecordBatch incoming,
FragmentContext context) |
Constructor and Description |
---|
RemovingRecordBatch(SelectionVectorRemover popConfig,
FragmentContext context,
RecordBatch incoming) |
Modifier and Type | Method and Description |
---|---|
static 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) |
Constructor and Description |
---|
SimpleSV4RecordBatch(VectorContainer container,
SelectionVector4 sv4,
FragmentContext context) |
TopNBatch(TopN popConfig,
FragmentContext context,
RecordBatch incoming) |
Constructor and Description |
---|
TraceRecordBatch(Trace pop,
RecordBatch incoming,
FragmentContext context) |
Modifier and Type | Method and Description |
---|---|
abstract void |
UnionAllerTemplate.doSetup(FragmentContext context,
RecordBatch incoming,
RecordBatch outgoing) |
void |
UnionAller.setup(FragmentContext context,
RecordBatch incoming,
RecordBatch outgoing,
List<TransferPair> transfers) |
void |
UnionAllerTemplate.setup(FragmentContext context,
RecordBatch incoming,
RecordBatch outgoing,
List<TransferPair> transfers) |
Constructor and Description |
---|
UnionAllRecordBatch(UnionAll config,
List<RecordBatch> children,
FragmentContext context) |
Modifier and Type | Method and Description |
---|---|
void |
UnnestImpl.setup(FragmentContext context,
RecordBatch incoming,
RecordBatch outgoing,
List<TransferPair> transfers) |
void |
Unnest.setup(FragmentContext context,
RecordBatch incoming,
RecordBatch outgoing,
List<TransferPair> transfers) |
Constructor and Description |
---|
UnnestRecordBatch(UnnestPOP pop,
FragmentContext context) |
Modifier and Type | Method and Description |
---|---|
FragmentContext |
UnorderedReceiverBatch.getContext() |
Constructor and Description |
---|
UnpivotMapsRecordBatch(UnpivotMaps pop,
RecordBatch incoming,
FragmentContext context) |
Modifier and Type | Method and Description |
---|---|
FragmentContext |
IteratorValidatorBatchIterator.getContext() |
Modifier and Type | Method and Description |
---|---|
static FragmentRoot |
IteratorValidatorInjector.rewritePlanWithIteratorValidator(FragmentContext context,
FragmentRoot root) |
PhysicalOperator |
IteratorValidatorInjector.visitOp(PhysicalOperator op,
FragmentContext context)
Traverse the physical plan and inject the IteratorValidator operator after every operator.
|
Constructor and Description |
---|
WindowFrameRecordBatch(WindowPOP popConfig,
FragmentContext context,
RecordBatch incoming) |
Modifier and Type | Method and Description |
---|---|
abstract void |
SingleBatchSorterTemplate.doSetup(FragmentContext context,
VectorAccessible incoming,
RecordBatch outgoing) |
abstract void |
MSortTemplate.doSetup(FragmentContext context,
VectorContainer 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) |
Constructor and Description |
---|
ExternalSortBatch(ExternalSort popConfig,
FragmentContext context,
RecordBatch incoming) |
Modifier and Type | Field and Description |
---|---|
protected FragmentContext |
AbstractRecordBatch.context |
Modifier and Type | Method and Description |
---|---|
FragmentContext |
RecordBatch.getContext()
Gets the FragmentContext of the current query fragment.
|
FragmentContext |
SchemalessBatch.getContext() |
FragmentContext |
SimpleRecordBatch.getContext() |
FragmentContext |
AbstractRecordBatch.getContext() |
Modifier and Type | Method and Description |
---|---|
void |
RawFragmentBatchProvider.kill(FragmentContext context) |
Constructor and Description |
---|
AbstractBinaryRecordBatch(T popConfig,
FragmentContext context,
boolean buildSchema,
RecordBatch left,
RecordBatch right) |
AbstractBinaryRecordBatch(T popConfig,
FragmentContext context,
RecordBatch left,
RecordBatch right) |
AbstractRecordBatch(T popConfig,
FragmentContext context) |
AbstractRecordBatch(T popConfig,
FragmentContext context,
boolean buildSchema) |
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) |
Modifier and Type | Field and Description |
---|---|
protected FragmentContext |
CommonParquetRecordReader.fragmentContext |
Constructor and Description |
---|
CommonParquetRecordReader(org.apache.parquet.hadoop.metadata.ParquetMetadata footer,
FragmentContext fragmentContext) |
Modifier and Type | Method and Description |
---|---|
protected CloseableRecordBatch |
EasyFormatPlugin.getReaderBatch(FragmentContext context,
EasySubScan scan) |
RecordReader |
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 original
ScanBatch scanner. |
RecordWriter |
EasyFormatPlugin.getRecordWriter(FragmentContext context,
EasyWriter writer) |
StatisticsRecordWriter |
EasyFormatPlugin.getStatisticsRecordWriter(FragmentContext context,
EasyWriter writer) |
CloseableRecordBatch |
EasyFormatPlugin.getWriterBatch(FragmentContext context,
RecordBatch incoming,
EasyWriter writer) |
boolean |
EasyFormatPlugin.isStatisticsRecordWriter(FragmentContext context,
EasyWriter writer) |
Constructor and Description |
---|
DruidRecordReader(DruidSubScan.DruidSubScanSpec subScanSpec,
List<SchemaPath> projectedColumns,
int maxRecordsToRead,
FragmentContext context,
DruidStoragePlugin plugin) |
Modifier and Type | Method and Description |
---|---|
RecordReader |
JSONFormatPlugin.getRecordReader(FragmentContext context,
DrillFileSystem dfs,
FileWork fileWork,
List<SchemaPath> columns,
String userName) |
RecordWriter |
JSONFormatPlugin.getRecordWriter(FragmentContext context,
EasyWriter writer) |
StatisticsRecordWriter |
JSONFormatPlugin.getStatisticsRecordWriter(FragmentContext context,
EasyWriter writer) |
boolean |
JSONFormatPlugin.isStatisticsRecordWriter(FragmentContext context,
EasyWriter writer) |
Constructor and Description |
---|
JSONRecordReader(FragmentContext fragmentContext,
com.fasterxml.jackson.databind.JsonNode embeddedContent,
DrillFileSystem fileSystem,
List<SchemaPath> columns)
Create a new JSON Record Reader that uses a in memory materialized JSON stream.
|
JSONRecordReader(FragmentContext fragmentContext,
List<SchemaPath> columns)
Create a JSON Record Reader that uses an InputStream directly
|
JSONRecordReader(FragmentContext fragmentContext,
org.apache.hadoop.fs.Path inputPath,
DrillFileSystem fileSystem,
List<SchemaPath> columns)
Create a JSON Record Reader that uses a file based input stream.
|
Modifier and Type | Method and Description |
---|---|
RecordWriter |
TextFormatPlugin.getRecordWriter(FragmentContext context,
EasyWriter writer) |
Constructor and Description |
---|
HiveDefaultRecordReader(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.
|
Modifier and Type | Method and Description |
---|---|
RecordReader |
LTSVFormatPlugin.getRecordReader(FragmentContext context,
DrillFileSystem dfs,
FileWork fileWork,
List<SchemaPath> columns,
String userName) |
RecordWriter |
LTSVFormatPlugin.getRecordWriter(FragmentContext context,
EasyWriter writer) |
Constructor and Description |
---|
LTSVRecordReader(FragmentContext fragmentContext,
org.apache.hadoop.fs.Path path,
DrillFileSystem fileSystem,
List<SchemaPath> columns) |
Constructor and Description |
---|
MaprDBJsonRecordReader(MapRDBSubScanSpec subScanSpec,
MapRDBFormatPlugin formatPlugin,
List<SchemaPath> projectedColumns,
FragmentContext context,
int maxRecords,
TupleMetadata schema) |
MaprDBJsonRecordReader(MapRDBSubScanSpec subScanSpec,
MapRDBFormatPlugin formatPlugin,
List<SchemaPath> projectedColumns,
FragmentContext context,
TupleMetadata schema) |
RestrictedJsonRecordReader(MapRDBSubScanSpec subScanSpec,
MapRDBFormatPlugin formatPlugin,
List<SchemaPath> projectedColumns,
FragmentContext context,
int maxRecordsToRead,
TupleMetadata schema) |
Constructor and Description |
---|
MockRecordReader(FragmentContext context,
MockTableDef.MockScanEntry config) |
Constructor and Description |
---|
MongoRecordReader(BaseMongoSubScanSpec subScanSpec,
List<SchemaPath> projectedColumns,
FragmentContext context,
MongoStoragePlugin plugin) |
Modifier and Type | Method and Description |
---|---|
static RowsMatch |
FilterEvaluatorUtils.evalFilter(LogicalExpression expr,
MetadataBase.ParquetTableMetadataBase footer,
int rowGroupIndex,
OptionManager options,
FragmentContext fragmentContext) |
RecordWriter |
ParquetFormatPlugin.getRecordWriter(FragmentContext context,
ParquetWriter writer) |
WriterRecordBatch |
ParquetFormatPlugin.getWriterBatch(FragmentContext context,
RecordBatch incoming,
ParquetWriter writer) |
Constructor and Description |
---|
ParquetRecordWriter(FragmentContext context,
ParquetWriter writer) |
Modifier and Type | Method and Description |
---|---|
FragmentContext |
ParquetRecordReader.getFragmentContext() |
Constructor and Description |
---|
ParquetRecordReader(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,
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) |
Constructor and Description |
---|
DrillParquetReader(FragmentContext fragmentContext,
org.apache.parquet.hadoop.metadata.ParquetMetadata footer,
RowGroupReadEntry entry,
List<SchemaPath> columns,
DrillFileSystem fileSystem,
ParquetReaderUtility.DateCorruptionStatus containsCorruptedDates,
long recordsToRead) |
Constructor and Description |
---|
AliasesIterator(FragmentContext context,
AliasTarget aliasTarget,
int maxRecords) |
ExtendedOptionIterator(FragmentContext context,
boolean internal) |
OptionIterator(FragmentContext context,
org.apache.drill.exec.store.sys.OptionIterator.Mode mode) |
Modifier and Type | Method and Description |
---|---|
static String |
Utilities.getFileNameForQueryFragment(FragmentContext context,
String location,
String tag) |
Constructor and Description |
---|
RecordBatchStatsContext(FragmentContext context,
OperatorContext oContext) |
Modifier and Type | Field and Description |
---|---|
protected FragmentContext |
BaseRawBatchBuffer.context |
Modifier and Type | Method and Description |
---|---|
void |
BaseRawBatchBuffer.kill(FragmentContext context) |
void |
SpoolingRawBatchBuffer.kill(FragmentContext context) |
Constructor and Description |
---|
AbstractDataCollector(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) |
Modifier and Type | Method and Description |
---|---|
FragmentContext |
AbstractFragmentManager.getFragmentContext() |
FragmentContext |
FragmentManager.getFragmentContext() |
Copyright © 1970 The Apache Software Foundation. All rights reserved.