Uses of Interface
org.apache.drill.exec.ops.ExecutorFragmentContext
Package
Description
Drill storage plugin.
Kafka storage plugin.
Defines a mock data source which generates dummy test data for use
in testing.
MongoDB storage plugin.
-
Uses of ExecutorFragmentContext in org.apache.drill.exec.ops
Modifier and TypeClassDescriptionclass
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. -
Uses of ExecutorFragmentContext in org.apache.drill.exec.physical.base
Modifier and TypeMethodDescriptionSchemalessBatchCreator.getBatch
(ExecutorFragmentContext context, SchemalessScan subScan, List<RecordBatch> children) -
Uses of ExecutorFragmentContext in org.apache.drill.exec.physical.impl
Modifier and TypeMethodDescriptionBatchCreator.getBatch
(ExecutorFragmentContext context, T config, List<RecordBatch> children) MergingReceiverCreator.getBatch
(ExecutorFragmentContext context, MergingReceiverPOP receiver, List<RecordBatch> children) static RootExec
ImplCreator.getExec
(ExecutorFragmentContext context, FragmentRoot root) Create and return fragment RootExec for given FragmentRoot.ImplCreator.getRecordBatch
(PhysicalOperator op, ExecutorFragmentContext context) Create a RecordBatch and its children for given PhysicalOperatorRootCreator.getRoot
(ExecutorFragmentContext context, T config, List<RecordBatch> children) ScreenCreator.getRoot
(ExecutorFragmentContext context, Screen config, List<RecordBatch> children) SingleSenderCreator.getRoot
(ExecutorFragmentContext context, SingleSender config, List<RecordBatch> children) -
Uses of ExecutorFragmentContext in org.apache.drill.exec.physical.impl.aggregate
Modifier and TypeMethodDescriptionHashAggBatchCreator.getBatch
(ExecutorFragmentContext context, HashAggregate config, List<RecordBatch> children) StreamingAggBatchCreator.getBatch
(ExecutorFragmentContext context, StreamingAggregate config, List<RecordBatch> children) -
Uses of ExecutorFragmentContext in org.apache.drill.exec.physical.impl.broadcastsender
Modifier and TypeMethodDescriptionBroadcastSenderCreator.getRoot
(ExecutorFragmentContext context, BroadcastSender config, List<RecordBatch> children) -
Uses of ExecutorFragmentContext in org.apache.drill.exec.physical.impl.filter
Modifier and TypeMethodDescriptionFilterBatchCreator.getBatch
(ExecutorFragmentContext context, Filter config, List<RecordBatch> children) RuntimeFilterBatchCreator.getBatch
(ExecutorFragmentContext context, RuntimeFilterPOP config, List<RecordBatch> children) -
Uses of ExecutorFragmentContext in org.apache.drill.exec.physical.impl.flatten
Modifier and TypeMethodDescriptionFlattenBatchCreator.getBatch
(ExecutorFragmentContext context, FlattenPOP config, List<RecordBatch> children) -
Uses of ExecutorFragmentContext in org.apache.drill.exec.physical.impl.join
Modifier and TypeMethodDescriptionHashJoinBatchCreator.getBatch
(ExecutorFragmentContext context, HashJoinPOP config, List<RecordBatch> children) LateralJoinBatchCreator.getBatch
(ExecutorFragmentContext context, LateralJoinPOP config, List<RecordBatch> children) MergeJoinCreator.getBatch
(ExecutorFragmentContext context, MergeJoinPOP config, List<RecordBatch> children) NestedLoopJoinBatchCreator.getBatch
(ExecutorFragmentContext context, NestedLoopJoinPOP config, List<RecordBatch> children) RowKeyJoinBatchCreator.getBatch
(ExecutorFragmentContext context, RowKeyJoinPOP config, List<RecordBatch> children) -
Uses of ExecutorFragmentContext in org.apache.drill.exec.physical.impl.limit
Modifier and TypeMethodDescriptionLimitBatchCreator.getBatch
(ExecutorFragmentContext context, Limit config, List<RecordBatch> children) PartitionLimitBatchCreator.getBatch
(ExecutorFragmentContext context, PartitionLimit config, List<RecordBatch> children) -
Uses of ExecutorFragmentContext in org.apache.drill.exec.physical.impl.metadata
Modifier and TypeMethodDescriptionMetadataControllerBatchCreator.getBatch
(ExecutorFragmentContext context, MetadataControllerPOP config, List<RecordBatch> children) MetadataHandlerBatchCreator.getBatch
(ExecutorFragmentContext context, MetadataHandlerPOP config, List<RecordBatch> children) MetadataHashAggBatchCreator.getBatch
(ExecutorFragmentContext context, MetadataHashAggPOP config, List<RecordBatch> children) MetadataStreamAggBatchCreator.getBatch
(ExecutorFragmentContext context, MetadataStreamAggPOP config, List<RecordBatch> children) -
Uses of ExecutorFragmentContext in org.apache.drill.exec.physical.impl.orderedpartitioner
Modifier and TypeMethodDescriptionOrderedPartitionSenderCreator.getRoot
(ExecutorFragmentContext context, OrderedPartitionSender config, List<RecordBatch> children) -
Uses of ExecutorFragmentContext in org.apache.drill.exec.physical.impl.partitionsender
Modifier and TypeMethodDescriptionPartitionSenderCreator.getRoot
(ExecutorFragmentContext context, HashPartitionSender config, List<RecordBatch> children) -
Uses of ExecutorFragmentContext in org.apache.drill.exec.physical.impl.producer
Modifier and TypeMethodDescriptionProducerConsumerBatchCreator.getBatch
(ExecutorFragmentContext context, ProducerConsumer config, List<RecordBatch> children) -
Uses of ExecutorFragmentContext in org.apache.drill.exec.physical.impl.project
Modifier and TypeMethodDescriptionComplexToJsonBatchCreator.getBatch
(ExecutorFragmentContext context, ComplexToJson flatten, List<RecordBatch> children) ProjectBatchCreator.getBatch
(ExecutorFragmentContext context, Project config, List<RecordBatch> children) -
Uses of ExecutorFragmentContext in org.apache.drill.exec.physical.impl.rangepartitioner
Modifier and TypeMethodDescriptionRangePartitionSenderCreator.getRoot
(ExecutorFragmentContext context, RangePartitionSender config, List<RecordBatch> children) -
Uses of ExecutorFragmentContext in org.apache.drill.exec.physical.impl.setop
Modifier and TypeMethodDescriptionSetOpBatchCreator.getBatch
(ExecutorFragmentContext context, SetOp config, List<RecordBatch> children) -
Uses of ExecutorFragmentContext in org.apache.drill.exec.physical.impl.sort
Modifier and TypeMethodDescriptionSortBatchCreator.getBatch
(ExecutorFragmentContext context, Sort config, List<RecordBatch> children) -
Uses of ExecutorFragmentContext in org.apache.drill.exec.physical.impl.statistics
Modifier and TypeMethodDescriptionStatisticsAggBatchCreator.getBatch
(ExecutorFragmentContext context, StatisticsAggregate config, List<RecordBatch> children) StatisticsMergeBatchCreator.getBatch
(ExecutorFragmentContext context, StatisticsMerge config, List<RecordBatch> children) -
Uses of ExecutorFragmentContext in org.apache.drill.exec.physical.impl.svremover
Modifier and TypeMethodDescriptionSVRemoverCreator.getBatch
(ExecutorFragmentContext context, SelectionVectorRemover config, List<RecordBatch> children) -
Uses of ExecutorFragmentContext in org.apache.drill.exec.physical.impl.TopN
Modifier and TypeMethodDescriptionTopNSortBatchCreator.getBatch
(ExecutorFragmentContext context, TopN config, List<RecordBatch> children) -
Uses of ExecutorFragmentContext in org.apache.drill.exec.physical.impl.trace
Modifier and TypeMethodDescriptionTraceBatchCreator.getBatch
(ExecutorFragmentContext context, Trace config, List<RecordBatch> children) -
Uses of ExecutorFragmentContext in org.apache.drill.exec.physical.impl.union
Modifier and TypeMethodDescriptionUnionAllBatchCreator.getBatch
(ExecutorFragmentContext context, UnionAll config, List<RecordBatch> children) -
Uses of ExecutorFragmentContext in org.apache.drill.exec.physical.impl.unnest
Modifier and TypeMethodDescriptionUnnestBatchCreator.getBatch
(ExecutorFragmentContext context, UnnestPOP config, List<RecordBatch> children) -
Uses of ExecutorFragmentContext in org.apache.drill.exec.physical.impl.unorderedreceiver
Modifier and TypeMethodDescriptionUnorderedReceiverCreator.getBatch
(ExecutorFragmentContext context, UnorderedReceiver receiver, List<RecordBatch> children) -
Uses of ExecutorFragmentContext in org.apache.drill.exec.physical.impl.unpivot
Modifier and TypeMethodDescriptionUnpivotMapsBatchCreator.getBatch
(ExecutorFragmentContext context, UnpivotMaps config, List<RecordBatch> children) -
Uses of ExecutorFragmentContext in org.apache.drill.exec.physical.impl.validate
Modifier and TypeMethodDescriptionIteratorValidatorCreator.getBatch
(ExecutorFragmentContext context, IteratorValidator config, List<RecordBatch> children) -
Uses of ExecutorFragmentContext in org.apache.drill.exec.physical.impl.values
Modifier and TypeMethodDescriptionValuesBatchCreator.getBatch
(ExecutorFragmentContext context, Values subScan, List<RecordBatch> children) -
Uses of ExecutorFragmentContext in org.apache.drill.exec.physical.impl.window
Modifier and TypeMethodDescriptionWindowFrameBatchCreator.getBatch
(ExecutorFragmentContext context, WindowPOP config, List<RecordBatch> children) -
Uses of ExecutorFragmentContext in org.apache.drill.exec.physical.impl.xsort
Modifier and TypeMethodDescriptionExternalSortBatchCreator.getBatch
(ExecutorFragmentContext context, ExternalSort config, List<RecordBatch> children) -
Uses of ExecutorFragmentContext in org.apache.drill.exec.store.delta.read
Modifier and TypeMethodDescriptionDeltaScanBatchCreator.getBatch
(ExecutorFragmentContext context, DeltaRowGroupScan rowGroupScan, List<RecordBatch> children) -
Uses of ExecutorFragmentContext in org.apache.drill.exec.store.dfs.easy
Modifier and TypeMethodDescriptionEasyReaderBatchCreator.getBatch
(ExecutorFragmentContext context, EasySubScan config, List<RecordBatch> children) EasyWriterBatchCreator.getBatch
(ExecutorFragmentContext context, EasyWriter config, List<RecordBatch> children) -
Uses of ExecutorFragmentContext in org.apache.drill.exec.store.direct
Modifier and TypeMethodDescriptionDirectBatchCreator.getBatch
(ExecutorFragmentContext context, DirectSubScan config, List<RecordBatch> children) -
Uses of ExecutorFragmentContext in org.apache.drill.exec.store.drill.plugin
Modifier and TypeMethodDescriptionDrillScanBatchCreator.getBatch
(ExecutorFragmentContext context, DrillSubScan subScan, List<RecordBatch> children) ModifierConstructorDescriptionDrillRecordReader
(ExecutorFragmentContext context, DrillSubScan config) -
Uses of ExecutorFragmentContext in org.apache.drill.exec.store.druid
Modifier and TypeMethodDescriptionDruidScanBatchCreator.getBatch
(ExecutorFragmentContext context, DruidSubScan subScan, List<RecordBatch> children) -
Uses of ExecutorFragmentContext in org.apache.drill.exec.store.enumerable
Modifier and TypeMethodDescriptionEnumerableBatchCreator.getBatch
(ExecutorFragmentContext context, EnumerableSubScan subScan, List<RecordBatch> children) -
Uses of ExecutorFragmentContext in org.apache.drill.exec.store.googlesheets
Modifier and TypeMethodDescriptionGoogleSheetsInsertWriterBatchCreator.getBatch
(ExecutorFragmentContext context, GoogleSheetsInsertWriter config, List<RecordBatch> children) GoogleSheetsScanBatchCreator.getBatch
(ExecutorFragmentContext context, GoogleSheetsSubScan subScan, List<RecordBatch> children) GoogleSheetsWriterBatchCreator.getBatch
(ExecutorFragmentContext context, GoogleSheetsWriter config, List<RecordBatch> children) -
Uses of ExecutorFragmentContext in org.apache.drill.exec.store.hbase
Modifier and TypeMethodDescriptionHBaseScanBatchCreator.getBatch
(ExecutorFragmentContext context, HBaseSubScan subScan, List<RecordBatch> children) -
Uses of ExecutorFragmentContext in org.apache.drill.exec.store.hive
Modifier and TypeMethodDescriptionHiveDrillNativeParquetScanBatchCreator.getBatch
(ExecutorFragmentContext context, HiveDrillNativeParquetRowGroupScan rowGroupScan, List<RecordBatch> children) HiveScanBatchCreator.getBatch
(ExecutorFragmentContext context, HiveSubScan config, List<RecordBatch> children) -
Uses of ExecutorFragmentContext in org.apache.drill.exec.store.hive.readers
Modifier and TypeMethodDescriptionstatic List<RecordReader>
ReadersInitializer.init
(ExecutorFragmentContext ctx, HiveSubScan config) Selects reader constructor reference asReadersInitializer.HiveReaderFactory
readerFactory. -
Uses of ExecutorFragmentContext in org.apache.drill.exec.store.http
Modifier and TypeMethodDescriptionHttpScanBatchCreator.getBatch
(ExecutorFragmentContext context, HttpSubScan subScan, List<RecordBatch> children) -
Uses of ExecutorFragmentContext in org.apache.drill.exec.store.iceberg.read
Modifier and TypeMethodDescriptionIcebergScanBatchCreator.getBatch
(ExecutorFragmentContext context, IcebergSubScan subScan, List<RecordBatch> children) -
Uses of ExecutorFragmentContext in org.apache.drill.exec.store.ischema
Modifier and TypeMethodDescriptionInfoSchemaBatchCreator.getBatch
(ExecutorFragmentContext context, InfoSchemaSubScan config, List<RecordBatch> children) -
Uses of ExecutorFragmentContext in org.apache.drill.exec.store.jdbc
Modifier and TypeMethodDescriptionJdbcInsertWriterBatchCreator.getBatch
(ExecutorFragmentContext context, JdbcInsertWriter config, List<RecordBatch> children) JdbcScanBatchCreator.getBatch
(ExecutorFragmentContext context, JdbcSubScan subScan, List<RecordBatch> children) JdbcWriterBatchCreator.getBatch
(ExecutorFragmentContext context, JdbcWriter config, List<RecordBatch> children) -
Uses of ExecutorFragmentContext in org.apache.drill.exec.store.kafka
Modifier and TypeMethodDescriptionKafkaScanBatchCreator.getBatch
(ExecutorFragmentContext context, KafkaSubScan subScan, List<RecordBatch> children) -
Uses of ExecutorFragmentContext in org.apache.drill.exec.store.kudu
Modifier and TypeMethodDescriptionKuduScanBatchCreator.getBatch
(ExecutorFragmentContext context, KuduSubScan subScan, List<RecordBatch> children) KuduWriterBatchCreator.getBatch
(ExecutorFragmentContext context, KuduWriter config, List<RecordBatch> children) -
Uses of ExecutorFragmentContext in org.apache.drill.exec.store.mock
Modifier and TypeMethodDescriptionMockScanBatchCreator.getBatch
(ExecutorFragmentContext context, MockSubScanPOP config, List<RecordBatch> children) -
Uses of ExecutorFragmentContext in org.apache.drill.exec.store.mongo
Modifier and TypeMethodDescriptionMongoScanBatchCreator.getBatch
(ExecutorFragmentContext context, MongoSubScan subScan, List<RecordBatch> children) -
Uses of ExecutorFragmentContext in org.apache.drill.exec.store.openTSDB
Modifier and TypeMethodDescriptionOpenTSDBBatchCreator.getBatch
(ExecutorFragmentContext context, OpenTSDBSubScan subScan, List<RecordBatch> children) -
Uses of ExecutorFragmentContext in org.apache.drill.exec.store.parquet
Modifier and TypeMethodDescriptionprotected ScanBatch
AbstractParquetScanBatchCreator.getBatch
(ExecutorFragmentContext context, AbstractParquetRowGroupScan rowGroupScan, OperatorContext oContext) ParquetScanBatchCreator.getBatch
(ExecutorFragmentContext context, ParquetRowGroupScan rowGroupScan, List<RecordBatch> children) ParquetWriterBatchCreator.getBatch
(ExecutorFragmentContext context, ParquetWriter config, List<RecordBatch> children) -
Uses of ExecutorFragmentContext in org.apache.drill.exec.store.phoenix
Modifier and TypeMethodDescriptionPhoenixScanBatchCreator.getBatch
(ExecutorFragmentContext context, PhoenixSubScan subScan, List<RecordBatch> children) -
Uses of ExecutorFragmentContext in org.apache.drill.exec.store.splunk
Modifier and TypeMethodDescriptionSplunkInsertWriterBatchCreator.getBatch
(ExecutorFragmentContext context, SplunkInsertWriter config, List<RecordBatch> children) SplunkScanBatchCreator.getBatch
(ExecutorFragmentContext context, SplunkSubScan subScan, List<RecordBatch> children) SplunkWriterBatchCreator.getBatch
(ExecutorFragmentContext context, SplunkWriter config, List<RecordBatch> children) -
Uses of ExecutorFragmentContext in org.apache.drill.exec.store.sys
Modifier and TypeMethodDescriptionSystemTableBatchCreator.getBatch
(ExecutorFragmentContext context, SystemTableScan scan, List<RecordBatch> children) SystemTable.getIterator
(ExecutorFragmentContext context, int maxRecords) ModifierConstructorDescriptionFunctionsIterator
(ExecutorFragmentContext context) MemoryIterator
(ExecutorFragmentContext context) ProfileInfoIterator
(ExecutorFragmentContext context, int maxRecords) protected
ProfileIterator
(ExecutorFragmentContext context, int maxRecords) ProfileJsonIterator
(ExecutorFragmentContext context, int maxRecords) ThreadsIterator
(ExecutorFragmentContext context) -
Uses of ExecutorFragmentContext in org.apache.drill.exec.work.filter
-
Uses of ExecutorFragmentContext in org.apache.drill.exec.work.fragment
Modifier and TypeFieldDescriptionprotected final ExecutorFragmentContext
FragmentStatusReporter.context
protected final ExecutorFragmentContext
AbstractFragmentManager.fragmentContext
ModifierConstructorDescriptionFragmentExecutor
(ExecutorFragmentContext context, BitControl.PlanFragment fragment, FragmentStatusReporter statusReporter) Create a FragmentExecutor where we need to parse and materialize the root operator.FragmentExecutor
(ExecutorFragmentContext context, BitControl.PlanFragment fragment, FragmentStatusReporter statusReporter, FragmentRoot rootOperator) Create a FragmentExecutor where we already have a root operator in memory.