Modifier and Type | Method and Description |
---|---|
static ExecutionSetupException |
ExecutionSetupException.fromThrowable(String message,
Throwable cause) |
Modifier and Type | Class and Description |
---|---|
class |
FragmentSetupException |
class |
OptimizerException |
Constructor and Description |
---|
FragmentContextImpl(DrillbitContext dbContext,
BitControl.PlanFragment fragment,
FunctionImplementationRegistry funcRegistry)
Create a FragmentContext instance for non-root fragment.
|
FragmentContextImpl(DrillbitContext dbContext,
BitControl.PlanFragment fragment,
QueryContext queryContext,
UserClientConnection connection,
FunctionImplementationRegistry funcRegistry)
Create a FragmentContext instance for root fragment.
|
FragmentContextImpl(DrillbitContext dbContext,
BitControl.PlanFragment fragment,
UserClientConnection connection,
FunctionImplementationRegistry funcRegistry)
TODO: Remove this constructor when removing the SimpleRootExec (DRILL-2097).
|
Modifier and Type | Class and Description |
---|---|
class |
PhysicalOperatorSetupException |
Modifier and Type | Method and Description |
---|---|
CloseableRecordBatch |
SchemalessBatchCreator.getBatch(ExecutorFragmentContext context,
SchemalessScan subScan,
List<RecordBatch> children) |
PhysicalOperator |
AbstractSubScan.getNewWithChildren(List<PhysicalOperator> children) |
PhysicalOperator |
PhysicalOperator.getNewWithChildren(List<PhysicalOperator> children)
Regenerate with this node with a new set of children.
|
SubScan |
GroupScan.getSpecificScan(int minorFragmentId) |
Modifier and Type | Method and Description |
---|---|
PhysicalOperator |
UnnestPOP.getNewWithChildren(List<PhysicalOperator> children) |
PhysicalOperator |
Values.getNewWithChildren(List<PhysicalOperator> children) |
Modifier and Type | Method and Description |
---|---|
MergingRecordBatch |
MergingReceiverCreator.getBatch(ExecutorFragmentContext context,
MergingReceiverPOP receiver,
List<RecordBatch> children) |
CloseableRecordBatch |
BatchCreator.getBatch(ExecutorFragmentContext context,
T config,
List<RecordBatch> children) |
static RootExec |
ImplCreator.getExec(ExecutorFragmentContext context,
FragmentRoot root)
Create and return fragment RootExec for given FragmentRoot.
|
static PhysicalOperator |
TraceInjector.getExec(FragmentContext context,
FragmentRoot root) |
Object |
OperatorCreatorRegistry.getOperatorCreator(Class<?> operator) |
RecordBatch |
ImplCreator.getRecordBatch(PhysicalOperator op,
ExecutorFragmentContext context)
Create a RecordBatch and its children for given PhysicalOperator
|
RootExec |
RootCreator.getRoot(ExecutorFragmentContext context,
T config,
List<RecordBatch> children) |
PhysicalOperator |
TraceInjector.visitOp(PhysicalOperator op,
FragmentContext context)
Traverse the physical plan and inject the trace operator after
every operator.
|
Constructor and Description |
---|
ScanBatch(PhysicalOperator subScanConfig,
FragmentContext context,
List<RecordReader> readers) |
ScanBatch(PhysicalOperator subScanConfig,
FragmentContext context,
List<RecordReader> readerList,
boolean isRepeatableScan) |
Modifier and Type | Method and Description |
---|---|
HashAggBatch |
HashAggBatchCreator.getBatch(ExecutorFragmentContext context,
HashAggregate config,
List<RecordBatch> children) |
StreamingAggBatch |
StreamingAggBatchCreator.getBatch(ExecutorFragmentContext context,
StreamingAggregate config,
List<RecordBatch> children) |
Modifier and Type | Method and Description |
---|---|
RootExec |
BroadcastSenderCreator.getRoot(ExecutorFragmentContext context,
BroadcastSender config,
List<RecordBatch> children) |
Modifier and Type | Method and Description |
---|---|
FilterRecordBatch |
FilterBatchCreator.getBatch(ExecutorFragmentContext context,
Filter config,
List<RecordBatch> children) |
CloseableRecordBatch |
RuntimeFilterBatchCreator.getBatch(ExecutorFragmentContext context,
RuntimeFilterPOP config,
List<RecordBatch> children) |
Modifier and Type | Method and Description |
---|---|
FlattenRecordBatch |
FlattenBatchCreator.getBatch(ExecutorFragmentContext context,
FlattenPOP config,
List<RecordBatch> children) |
Modifier and Type | Method and Description |
---|---|
HashJoinBatch |
HashJoinBatchCreator.getBatch(ExecutorFragmentContext context,
HashJoinPOP config,
List<RecordBatch> children) |
LateralJoinBatch |
LateralJoinBatchCreator.getBatch(ExecutorFragmentContext context,
LateralJoinPOP config,
List<RecordBatch> children) |
MergeJoinBatch |
MergeJoinCreator.getBatch(ExecutorFragmentContext context,
MergeJoinPOP config,
List<RecordBatch> children) |
NestedLoopJoinBatch |
NestedLoopJoinBatchCreator.getBatch(ExecutorFragmentContext context,
NestedLoopJoinPOP config,
List<RecordBatch> children) |
RowKeyJoinBatch |
RowKeyJoinBatchCreator.getBatch(ExecutorFragmentContext context,
RowKeyJoinPOP config,
List<RecordBatch> children) |
Modifier and Type | Method and Description |
---|---|
LimitRecordBatch |
LimitBatchCreator.getBatch(ExecutorFragmentContext context,
Limit config,
List<RecordBatch> children) |
PartitionLimitRecordBatch |
PartitionLimitBatchCreator.getBatch(ExecutorFragmentContext context,
PartitionLimit config,
List<RecordBatch> children) |
Modifier and Type | Method and Description |
---|---|
CloseableRecordBatch |
MetadataControllerBatchCreator.getBatch(ExecutorFragmentContext context,
MetadataControllerPOP config,
List<RecordBatch> children) |
CloseableRecordBatch |
MetadataHandlerBatchCreator.getBatch(ExecutorFragmentContext context,
MetadataHandlerPOP config,
List<RecordBatch> children) |
CloseableRecordBatch |
MetadataHashAggBatchCreator.getBatch(ExecutorFragmentContext context,
MetadataHashAggPOP config,
List<RecordBatch> children) |
CloseableRecordBatch |
MetadataStreamAggBatchCreator.getBatch(ExecutorFragmentContext context,
MetadataStreamAggPOP config,
List<RecordBatch> children) |
Modifier and Type | Method and Description |
---|---|
RootExec |
OrderedPartitionSenderCreator.getRoot(ExecutorFragmentContext context,
OrderedPartitionSender config,
List<RecordBatch> children) |
Modifier and Type | Method and Description |
---|---|
RootExec |
PartitionSenderCreator.getRoot(ExecutorFragmentContext context,
HashPartitionSender config,
List<RecordBatch> children) |
Modifier and Type | Method and Description |
---|---|
ProducerConsumerBatch |
ProducerConsumerBatchCreator.getBatch(ExecutorFragmentContext context,
ProducerConsumer config,
List<RecordBatch> children) |
Modifier and Type | Method and Description |
---|---|
ProjectRecordBatch |
ComplexToJsonBatchCreator.getBatch(ExecutorFragmentContext context,
ComplexToJson flatten,
List<RecordBatch> children) |
ProjectRecordBatch |
ProjectBatchCreator.getBatch(ExecutorFragmentContext context,
Project config,
List<RecordBatch> children) |
Modifier and Type | Method and Description |
---|---|
RootExec |
RangePartitionSenderCreator.getRoot(ExecutorFragmentContext context,
RangePartitionSender config,
List<RecordBatch> children) |
Modifier and Type | Method and Description |
---|---|
SortBatch |
SortBatchCreator.getBatch(ExecutorFragmentContext context,
Sort config,
List<RecordBatch> children) |
Modifier and Type | Method and Description |
---|---|
CloseableRecordBatch |
StatisticsAggBatchCreator.getBatch(ExecutorFragmentContext context,
StatisticsAggregate config,
List<RecordBatch> children) |
CloseableRecordBatch |
StatisticsMergeBatchCreator.getBatch(ExecutorFragmentContext context,
StatisticsMerge config,
List<RecordBatch> children) |
Modifier and Type | Method and Description |
---|---|
RemovingRecordBatch |
SVRemoverCreator.getBatch(ExecutorFragmentContext context,
SelectionVectorRemover config,
List<RecordBatch> children) |
Modifier and Type | Method and Description |
---|---|
TopNBatch |
TopNSortBatchCreator.getBatch(ExecutorFragmentContext context,
TopN config,
List<RecordBatch> children) |
Modifier and Type | Method and Description |
---|---|
TraceRecordBatch |
TraceBatchCreator.getBatch(ExecutorFragmentContext context,
Trace config,
List<RecordBatch> children) |
Constructor and Description |
---|
TraceRecordBatch(Trace pop,
RecordBatch incoming,
FragmentContext context) |
Modifier and Type | Method and Description |
---|---|
UnionAllRecordBatch |
UnionAllBatchCreator.getBatch(ExecutorFragmentContext context,
UnionAll config,
List<RecordBatch> children) |
Modifier and Type | Method and Description |
---|---|
UnnestRecordBatch |
UnnestBatchCreator.getBatch(ExecutorFragmentContext context,
UnnestPOP config,
List<RecordBatch> children) |
Modifier and Type | Method and Description |
---|---|
UnorderedReceiverBatch |
UnorderedReceiverCreator.getBatch(ExecutorFragmentContext context,
UnorderedReceiver receiver,
List<RecordBatch> children) |
Modifier and Type | Method and Description |
---|---|
CloseableRecordBatch |
UnpivotMapsBatchCreator.getBatch(ExecutorFragmentContext context,
UnpivotMaps config,
List<RecordBatch> children) |
Modifier and Type | Method and Description |
---|---|
IteratorValidatorBatchIterator |
IteratorValidatorCreator.getBatch(ExecutorFragmentContext context,
IteratorValidator config,
List<RecordBatch> children) |
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.
|
Modifier and Type | Method and Description |
---|---|
ScanBatch |
ValuesBatchCreator.getBatch(ExecutorFragmentContext context,
Values config,
List<RecordBatch> children) |
Modifier and Type | Method and Description |
---|---|
WindowFrameRecordBatch |
WindowFrameBatchCreator.getBatch(ExecutorFragmentContext context,
WindowPOP config,
List<RecordBatch> children) |
Modifier and Type | Method and Description |
---|---|
AbstractRecordBatch<ExternalSort> |
ExternalSortBatchCreator.getBatch(ExecutorFragmentContext context,
ExternalSort config,
List<RecordBatch> children) |
Constructor and Description |
---|
FileSystemCreateTableEntry(FileSystemConfig storageConfig,
FormatPluginConfig formatConfig,
String location,
List<String> partitionColumns,
StorageStrategy storageStrategy,
StoragePluginRegistry engineRegistry) |
Modifier and Type | Class and Description |
---|---|
class |
QueryInputException |
Modifier and Type | Method and Description |
---|---|
void |
FindLimit0Visitor.RelDataTypeReader.setup(OperatorContext context,
OutputMutator output) |
Modifier and Type | Method and Description |
---|---|
StoragePlugin |
ClassicConnectorLocator.create(String name,
StoragePluginConfig pluginConfig)
Creates plugin instance with the given
name and configuration pluginConfig . |
FormatPlugin |
StoragePluginRegistry.getFormatPlugin(StoragePluginConfig storageConfig,
FormatPluginConfig formatConfig)
Deprecated.
use
StoragePluginRegistry.resolveFormat(StoragePluginConfig, FormatPluginConfig, Class)
which provides type safety. Retained for compatibility with older plugins |
FormatPlugin |
StoragePluginRegistryImpl.getFormatPlugin(StoragePluginConfig storageConfig,
FormatPluginConfig formatConfig) |
StoragePlugin |
StoragePluginRegistry.getPlugin(StoragePluginConfig config)
Deprecated.
use
StoragePluginRegistry.resolve(StoragePluginConfig, Class) which provides
type safety. Retained for compatibility with older plugins |
StoragePlugin |
StoragePluginRegistryImpl.getPlugin(StoragePluginConfig config) |
void |
RecordReader.setup(OperatorContext context,
OutputMutator output)
Configure the RecordReader with the provided schema and the record batch that should be written to.
|
Constructor and Description |
---|
FileSystemPlugin(FileSystemConfig config,
DrillbitContext context,
String name) |
WorkspaceSchemaFactory(FileSystemPlugin plugin,
String schemaName,
String storageEngineName,
WorkspaceConfig config,
List<FormatMatcher> formatMatchers,
com.fasterxml.jackson.databind.ObjectMapper mapper,
ScanResult scanResult) |
Constructor and Description |
---|
EasySubScan(String userName,
List<CompleteFileWork.FileWorkImpl> files,
StoragePluginConfig storageConfig,
FormatPluginConfig formatConfig,
StoragePluginRegistry engineRegistry,
List<SchemaPath> columns,
org.apache.hadoop.fs.Path selectionRoot,
int partitionDepth,
TupleMetadata schema,
int limit) |
Modifier and Type | Method and Description |
---|---|
ScanBatch |
DirectBatchCreator.getBatch(ExecutorFragmentContext context,
DirectSubScan config,
List<RecordBatch> children) |
Modifier and Type | Method and Description |
---|---|
CloseableRecordBatch |
DruidScanBatchCreator.getBatch(ExecutorFragmentContext context,
DruidSubScan subScan,
List<RecordBatch> children) |
Modifier and Type | Method and Description |
---|---|
void |
JSONRecordReader.setup(OperatorContext context,
OutputMutator output) |
Modifier and Type | Method and Description |
---|---|
protected FileScanFramework.FileScanBuilder |
SequenceFileFormatPlugin.frameworkBuilder(OptionManager options,
EasySubScan scan) |
ManagedReader<? extends FileScanFramework.FileSchemaNegotiator> |
SequenceFileFormatPlugin.newBatchReader(EasySubScan scan,
OptionManager options) |
Modifier and Type | Method and Description |
---|---|
protected FileScanFramework.FileScanBuilder |
TextFormatPlugin.frameworkBuilder(OptionManager options,
EasySubScan scan) |
Modifier and Type | Method and Description |
---|---|
CloseableRecordBatch |
EnumerableBatchCreator.getBatch(ExecutorFragmentContext context,
EnumerableSubScan subScan,
List<RecordBatch> children) |
Modifier and Type | Method and Description |
---|---|
ManagedReader<? extends FileScanFramework.FileSchemaNegotiator> |
ShpFormatPlugin.newBatchReader(EasySubScan scan,
OptionManager options) |
Modifier and Type | Method and Description |
---|---|
ScanBatch |
HBaseScanBatchCreator.getBatch(ExecutorFragmentContext context,
HBaseSubScan subScan,
List<RecordBatch> children) |
void |
HBaseRecordReader.setup(OperatorContext context,
OutputMutator output) |
Constructor and Description |
---|
HBaseGroupScan(String userName,
HBaseScanSpec hbaseScanSpec,
HBaseStoragePluginConfig storagePluginConfig,
List<SchemaPath> columns,
StoragePluginRegistry pluginRegistry) |
HBaseSubScan(StoragePluginRegistry registry,
String userName,
HBaseStoragePluginConfig hbaseStoragePluginConfig,
LinkedList<HBaseSubScan.HBaseSubScanSpec> regionScanSpecList,
List<SchemaPath> columns) |
Modifier and Type | Method and Description |
---|---|
HiveScan |
HiveScan.clone(HiveReadEntry hiveReadEntry) |
CloseableRecordBatch |
HiveDrillNativeParquetScanBatchCreator.getBatch(ExecutorFragmentContext context,
HiveDrillNativeParquetRowGroupScan rowGroupScan,
List<RecordBatch> children) |
ScanBatch |
HiveScanBatchCreator.getBatch(ExecutorFragmentContext context,
HiveSubScan config,
List<RecordBatch> children) |
PhysicalOperator |
HiveSubScan.getNewWithChildren(List<PhysicalOperator> children) |
SubScan |
HiveScan.getSpecificScan(int minorFragmentId) |
Modifier and Type | Method and Description |
---|---|
protected boolean |
HiveDefaultRecordReader.hasNextValue(Object valueHolder)
Checks and reads next value of input split into valueHolder.
|
void |
HiveDefaultRecordReader.setup(OperatorContext context,
OutputMutator output) |
Constructor and Description |
---|
HiveSchemaFactory(HiveStoragePlugin plugin,
String name,
org.apache.hadoop.hive.conf.HiveConf hiveConf) |
Modifier and Type | Method and Description |
---|---|
CloseableRecordBatch |
HttpScanBatchCreator.getBatch(ExecutorFragmentContext context,
HttpSubScan subScan,
List<RecordBatch> children) |
Modifier and Type | Method and Description |
---|---|
CloseableRecordBatch |
IcebergScanBatchCreator.getBatch(ExecutorFragmentContext context,
IcebergSubScan subScan,
List<RecordBatch> children) |
Modifier and Type | Method and Description |
---|---|
protected FileScanFramework.FileScanBuilder |
ImageFormatPlugin.frameworkBuilder(OptionManager options,
EasySubScan scan) |
ManagedReader<? extends FileScanFramework.FileSchemaNegotiator> |
ImageFormatPlugin.newBatchReader(EasySubScan scan,
OptionManager options) |
Modifier and Type | Method and Description |
---|---|
ScanBatch |
InfoSchemaBatchCreator.getBatch(ExecutorFragmentContext context,
InfoSchemaSubScan config,
List<RecordBatch> children) |
Modifier and Type | Method and Description |
---|---|
CloseableRecordBatch |
JdbcScanBatchCreator.getBatch(ExecutorFragmentContext context,
JdbcSubScan subScan,
List<RecordBatch> children) |
CloseableRecordBatch |
JdbcWriterBatchCreator.getBatch(ExecutorFragmentContext context,
JdbcWriter config,
List<RecordBatch> children) |
Constructor and Description |
---|
JdbcGroupScan(String sql,
List<SchemaPath> columns,
StoragePluginConfig config,
double rows,
StoragePluginRegistry plugins) |
JdbcSubScan(String sql,
List<SchemaPath> columns,
StoragePluginConfig config,
StoragePluginRegistry plugins) |
JdbcWriter(PhysicalOperator child,
String name,
StoragePluginConfig storageConfig,
org.apache.calcite.adapter.jdbc.JdbcSchema inner,
StoragePluginRegistry engineRegistry) |
Modifier and Type | Method and Description |
---|---|
CloseableRecordBatch |
KafkaScanBatchCreator.getBatch(ExecutorFragmentContext context,
KafkaSubScan subScan,
List<RecordBatch> children) |
Constructor and Description |
---|
KafkaGroupScan(String userName,
KafkaStoragePluginConfig kafkaStoragePluginConfig,
List<SchemaPath> columns,
KafkaScanSpec scanSpec,
StoragePluginRegistry pluginRegistry) |
KafkaSubScan(StoragePluginRegistry registry,
String userName,
KafkaStoragePluginConfig kafkaStoragePluginConfig,
List<SchemaPath> columns,
LinkedList<KafkaPartitionScanSpec> partitionSubScanSpecList) |
Modifier and Type | Method and Description |
---|---|
ScanBatch |
KuduScanBatchCreator.getBatch(ExecutorFragmentContext context,
KuduSubScan subScan,
List<RecordBatch> children) |
CloseableRecordBatch |
KuduWriterBatchCreator.getBatch(ExecutorFragmentContext context,
KuduWriter config,
List<RecordBatch> children) |
void |
KuduRecordReader.setup(OperatorContext context,
OutputMutator output) |
Constructor and Description |
---|
KuduGroupScan(KuduScanSpec kuduScanSpec,
KuduStoragePluginConfig kuduStoragePluginConfig,
List<SchemaPath> columns,
StoragePluginRegistry pluginRegistry) |
KuduSubScan(StoragePluginRegistry registry,
KuduStoragePluginConfig kuduStoragePluginConfig,
LinkedList<KuduSubScan.KuduSubScanSpec> tabletScanSpecList,
List<SchemaPath> columns) |
KuduWriter(PhysicalOperator child,
String name,
StoragePluginConfig storageConfig,
StoragePluginRegistry engineRegistry) |
Modifier and Type | Method and Description |
---|---|
protected FileScanFramework.FileScanBuilder |
LogFormatPlugin.frameworkBuilder(OptionManager options,
EasySubScan scan)
Build a file scan framework for this plugin.
|
Modifier and Type | Method and Description |
---|---|
ScanBatch |
MapRDBScanBatchCreator.getBatch(ExecutorFragmentContext context,
MapRDBSubScan subScan,
List<RecordBatch> children) |
ScanBatch |
MapRDBRestrictedScanBatchCreator.getBatch(ExecutorFragmentContext context,
RestrictedMapRDBSubScan subScan,
List<RecordBatch> children) |
Constructor and Description |
---|
MapRDBSubScan(StoragePluginRegistry engineRegistry,
String userName,
MapRDBFormatPluginConfig formatPluginConfig,
StoragePluginConfig storageConfig,
List<MapRDBSubScanSpec> regionScanSpecList,
List<SchemaPath> columns,
int maxRecordsToRead,
String tableType,
TupleMetadata schema) |
RestrictedMapRDBSubScan(StoragePluginRegistry engineRegistry,
String userName,
MapRDBFormatPluginConfig formatPluginConfig,
StoragePluginConfig storageConfig,
List<RestrictedMapRDBSubScanSpec> regionScanSpecList,
List<SchemaPath> columns,
int maxRecordsToRead,
String tableType,
TupleMetadata schema) |
Constructor and Description |
---|
BinaryTableGroupScan(String userName,
HBaseScanSpec scanSpec,
FileSystemConfig storagePluginConfig,
MapRDBFormatPluginConfig formatPluginConfig,
List<SchemaPath> columns,
TupleMetadata schema,
StoragePluginRegistry pluginRegistry) |
Modifier and Type | Method and Description |
---|---|
void |
MaprDBJsonRecordReader.setup(OperatorContext context,
OutputMutator output) |
void |
RestrictedJsonRecordReader.setup(OperatorContext context,
OutputMutator output) |
Constructor and Description |
---|
JsonTableGroupScan(String userName,
JsonScanSpec scanSpec,
FileSystemConfig storagePluginConfig,
MapRDBFormatPluginConfig formatPluginConfig,
List<SchemaPath> columns,
TupleMetadata schema,
StoragePluginRegistry pluginRegistry) |
Modifier and Type | Method and Description |
---|---|
CloseableRecordBatch |
MockScanBatchCreator.getBatch(ExecutorFragmentContext context,
MockSubScanPOP config,
List<RecordBatch> children) |
void |
MockRecordReader.setup(OperatorContext context,
OutputMutator output) |
Modifier and Type | Method and Description |
---|---|
ScanBatch |
MongoScanBatchCreator.getBatch(ExecutorFragmentContext context,
MongoSubScan subScan,
List<RecordBatch> children) |
void |
MongoRecordReader.setup(OperatorContext context,
OutputMutator output) |
Modifier and Type | Method and Description |
---|---|
CloseableRecordBatch |
OpenTSDBBatchCreator.getBatch(ExecutorFragmentContext context,
OpenTSDBSubScan subScan,
List<RecordBatch> children) |
PhysicalOperator |
OpenTSDBSubScan.getNewWithChildren(List<PhysicalOperator> children) |
Constructor and Description |
---|
OpenTSDBGroupScan(OpenTSDBScanSpec openTSDBScanSpec,
OpenTSDBStoragePluginConfig openTSDBStoragePluginConfig,
List<SchemaPath> columns,
StoragePluginRegistry pluginRegistry) |
OpenTSDBSubScan(StoragePluginRegistry registry,
OpenTSDBStoragePluginConfig storage,
LinkedList<OpenTSDBSubScan.OpenTSDBSubScanSpec> tabletScanSpecList,
List<SchemaPath> columns) |
Modifier and Type | Method and Description |
---|---|
protected abstract DrillFileSystem |
AbstractParquetScanBatchCreator.AbstractDrillFileSystemManager.get(org.apache.hadoop.conf.Configuration config,
org.apache.hadoop.fs.Path path) |
protected ScanBatch |
AbstractParquetScanBatchCreator.getBatch(ExecutorFragmentContext context,
AbstractParquetRowGroupScan rowGroupScan,
OperatorContext oContext) |
ScanBatch |
ParquetScanBatchCreator.getBatch(ExecutorFragmentContext context,
ParquetRowGroupScan rowGroupScan,
List<RecordBatch> children) |
WriterRecordBatch |
ParquetWriterBatchCreator.getBatch(ExecutorFragmentContext context,
ParquetWriter config,
List<RecordBatch> children) |
WriterRecordBatch |
ParquetFormatPlugin.getWriterBatch(FragmentContext context,
RecordBatch incoming,
ParquetWriter writer) |
Constructor and Description |
---|
ParquetRowGroupScan(StoragePluginRegistry registry,
String userName,
StoragePluginConfig storageConfig,
FormatPluginConfig formatConfig,
LinkedList<RowGroupReadEntry> rowGroupReadEntries,
List<SchemaPath> columns,
ParquetReaderConfig readerConfig,
org.apache.hadoop.fs.Path selectionRoot,
LogicalExpression filter,
TupleMetadata schema) |
ParquetWriter(PhysicalOperator child,
String location,
List<String> partitionColumns,
StorageStrategy storageStrategy,
StoragePluginConfig storageConfig,
StoragePluginRegistry engineRegistry) |
Modifier and Type | Method and Description |
---|---|
static ColumnReader<?> |
ColumnReaderFactory.getNullableColumnReader(ParquetRecordReader parentReader,
org.apache.parquet.column.ColumnDescriptor columnDescriptor,
org.apache.parquet.hadoop.metadata.ColumnChunkMetaData columnChunkMetaData,
boolean fixedLength,
ValueVector valueVec,
org.apache.parquet.format.SchemaElement schemaElement) |
void |
ParquetRecordReader.setup(OperatorContext operatorContext,
OutputMutator output)
Prepare the Parquet reader.
|
Constructor and Description |
---|
ColumnReader(ParquetRecordReader parentReader,
org.apache.parquet.column.ColumnDescriptor descriptor,
org.apache.parquet.hadoop.metadata.ColumnChunkMetaData columnChunkMetaData,
boolean fixedLength,
V v,
org.apache.parquet.format.SchemaElement schemaElement) |
Modifier and Type | Method and Description |
---|---|
void |
DrillParquetReader.setup(OperatorContext context,
OutputMutator output) |
Modifier and Type | Method and Description |
---|---|
CloseableRecordBatch |
PhoenixScanBatchCreator.getBatch(ExecutorFragmentContext context,
PhoenixSubScan subScan,
List<RecordBatch> children) |
PhysicalOperator |
PhoenixGroupScan.getNewWithChildren(List<PhysicalOperator> children) |
SubScan |
PhoenixGroupScan.getSpecificScan(int minorFragmentId) |
Modifier and Type | Method and Description |
---|---|
static PojoWriter |
PojoWriters.getWriter(Class<?> type,
String fieldName,
DrillBuf buffer)
Creates matching writer to the given field type.
|
protected PojoWriter |
AbstractPojoRecordReader.initWriter(Class<?> type,
String fieldName,
OutputMutator output)
Creates writer based input class type and then initiates it.
|
void |
AbstractPojoRecordReader.setup(OperatorContext context,
OutputMutator output) |
protected abstract List<PojoWriter> |
AbstractPojoRecordReader.setupWriters(OutputMutator output)
Setups writers for each field in the row.
|
protected List<PojoWriter> |
DynamicPojoRecordReader.setupWriters(OutputMutator output)
Initiates writers based on given schema which contains field name and its type.
|
protected List<PojoWriter> |
PojoRecordReader.setupWriters(OutputMutator output)
Creates writers based on pojo field class types.
|
Modifier and Type | Method and Description |
---|---|
CloseableRecordBatch |
SplunkScanBatchCreator.getBatch(ExecutorFragmentContext context,
SplunkSubScan subScan,
List<RecordBatch> children) |
Modifier and Type | Method and Description |
---|---|
ScanBatch |
SystemTableBatchCreator.getBatch(ExecutorFragmentContext context,
SystemTableScan scan,
List<RecordBatch> children) |
PersistentStoreProvider |
PersistentStoreRegistry.newPStoreProvider() |
Constructor and Description |
---|
SystemTableScan(SystemTable table,
int maxRecordsToRead,
StoragePluginRegistry engineRegistry) |
Modifier and Type | Class and Description |
---|---|
class |
ForemanException |
class |
ForemanSetupException |
class |
SqlUnsupportedException |
class |
UnsupportedDataTypeException |
class |
UnsupportedFunctionException |
class |
UnsupportedRelOperatorException |
Modifier and Type | Method and Description |
---|---|
void |
FragmentsRunner.submit()
Submits root and non-root fragments fragments for running.
|
Copyright © 1970 The Apache Software Foundation. All rights reserved.