Uses of Interface
org.apache.drill.exec.ops.ExecutorFragmentContext
Packages that use 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
Classes in org.apache.drill.exec.ops that implement ExecutorFragmentContextModifier and TypeClassDescriptionclassThis 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
Methods in org.apache.drill.exec.physical.base with parameters of type ExecutorFragmentContextModifier and TypeMethodDescriptionSchemalessBatchCreator.getBatch(ExecutorFragmentContext context, SchemalessScan subScan, List<RecordBatch> children) -
Uses of ExecutorFragmentContext in org.apache.drill.exec.physical.impl
Methods in org.apache.drill.exec.physical.impl with parameters of type ExecutorFragmentContextModifier and TypeMethodDescriptionBatchCreator.getBatch(ExecutorFragmentContext context, T config, List<RecordBatch> children) MergingReceiverCreator.getBatch(ExecutorFragmentContext context, MergingReceiverPOP receiver, List<RecordBatch> children) static RootExecImplCreator.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
Methods in org.apache.drill.exec.physical.impl.aggregate with parameters of type ExecutorFragmentContextModifier 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
Methods in org.apache.drill.exec.physical.impl.broadcastsender with parameters of type ExecutorFragmentContextModifier and TypeMethodDescriptionBroadcastSenderCreator.getRoot(ExecutorFragmentContext context, BroadcastSender config, List<RecordBatch> children) -
Uses of ExecutorFragmentContext in org.apache.drill.exec.physical.impl.filter
Methods in org.apache.drill.exec.physical.impl.filter with parameters of type ExecutorFragmentContextModifier 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
Methods in org.apache.drill.exec.physical.impl.flatten with parameters of type ExecutorFragmentContextModifier and TypeMethodDescriptionFlattenBatchCreator.getBatch(ExecutorFragmentContext context, FlattenPOP config, List<RecordBatch> children) -
Uses of ExecutorFragmentContext in org.apache.drill.exec.physical.impl.join
Methods in org.apache.drill.exec.physical.impl.join with parameters of type ExecutorFragmentContextModifier 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
Methods in org.apache.drill.exec.physical.impl.limit with parameters of type ExecutorFragmentContextModifier 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
Methods in org.apache.drill.exec.physical.impl.metadata with parameters of type ExecutorFragmentContextModifier 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
Methods in org.apache.drill.exec.physical.impl.orderedpartitioner with parameters of type ExecutorFragmentContextModifier and TypeMethodDescriptionOrderedPartitionSenderCreator.getRoot(ExecutorFragmentContext context, OrderedPartitionSender config, List<RecordBatch> children) -
Uses of ExecutorFragmentContext in org.apache.drill.exec.physical.impl.partitionsender
Methods in org.apache.drill.exec.physical.impl.partitionsender with parameters of type ExecutorFragmentContextModifier and TypeMethodDescriptionPartitionSenderCreator.getRoot(ExecutorFragmentContext context, HashPartitionSender config, List<RecordBatch> children) -
Uses of ExecutorFragmentContext in org.apache.drill.exec.physical.impl.producer
Methods in org.apache.drill.exec.physical.impl.producer with parameters of type ExecutorFragmentContextModifier and TypeMethodDescriptionProducerConsumerBatchCreator.getBatch(ExecutorFragmentContext context, ProducerConsumer config, List<RecordBatch> children) -
Uses of ExecutorFragmentContext in org.apache.drill.exec.physical.impl.project
Methods in org.apache.drill.exec.physical.impl.project with parameters of type ExecutorFragmentContextModifier 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
Methods in org.apache.drill.exec.physical.impl.rangepartitioner with parameters of type ExecutorFragmentContextModifier and TypeMethodDescriptionRangePartitionSenderCreator.getRoot(ExecutorFragmentContext context, RangePartitionSender config, List<RecordBatch> children) -
Uses of ExecutorFragmentContext in org.apache.drill.exec.physical.impl.setop
Methods in org.apache.drill.exec.physical.impl.setop with parameters of type ExecutorFragmentContextModifier and TypeMethodDescriptionSetOpBatchCreator.getBatch(ExecutorFragmentContext context, SetOp config, List<RecordBatch> children) -
Uses of ExecutorFragmentContext in org.apache.drill.exec.physical.impl.sort
Methods in org.apache.drill.exec.physical.impl.sort with parameters of type ExecutorFragmentContextModifier and TypeMethodDescriptionSortBatchCreator.getBatch(ExecutorFragmentContext context, Sort config, List<RecordBatch> children) -
Uses of ExecutorFragmentContext in org.apache.drill.exec.physical.impl.statistics
Methods in org.apache.drill.exec.physical.impl.statistics with parameters of type ExecutorFragmentContextModifier 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
Methods in org.apache.drill.exec.physical.impl.svremover with parameters of type ExecutorFragmentContextModifier and TypeMethodDescriptionSVRemoverCreator.getBatch(ExecutorFragmentContext context, SelectionVectorRemover config, List<RecordBatch> children) -
Uses of ExecutorFragmentContext in org.apache.drill.exec.physical.impl.TopN
Methods in org.apache.drill.exec.physical.impl.TopN with parameters of type ExecutorFragmentContextModifier and TypeMethodDescriptionTopNSortBatchCreator.getBatch(ExecutorFragmentContext context, TopN config, List<RecordBatch> children) -
Uses of ExecutorFragmentContext in org.apache.drill.exec.physical.impl.trace
Methods in org.apache.drill.exec.physical.impl.trace with parameters of type ExecutorFragmentContextModifier and TypeMethodDescriptionTraceBatchCreator.getBatch(ExecutorFragmentContext context, Trace config, List<RecordBatch> children) -
Uses of ExecutorFragmentContext in org.apache.drill.exec.physical.impl.union
Methods in org.apache.drill.exec.physical.impl.union with parameters of type ExecutorFragmentContextModifier and TypeMethodDescriptionUnionAllBatchCreator.getBatch(ExecutorFragmentContext context, UnionAll config, List<RecordBatch> children) -
Uses of ExecutorFragmentContext in org.apache.drill.exec.physical.impl.unnest
Methods in org.apache.drill.exec.physical.impl.unnest with parameters of type ExecutorFragmentContextModifier and TypeMethodDescriptionUnnestBatchCreator.getBatch(ExecutorFragmentContext context, UnnestPOP config, List<RecordBatch> children) -
Uses of ExecutorFragmentContext in org.apache.drill.exec.physical.impl.unorderedreceiver
Methods in org.apache.drill.exec.physical.impl.unorderedreceiver with parameters of type ExecutorFragmentContextModifier and TypeMethodDescriptionUnorderedReceiverCreator.getBatch(ExecutorFragmentContext context, UnorderedReceiver receiver, List<RecordBatch> children) -
Uses of ExecutorFragmentContext in org.apache.drill.exec.physical.impl.unpivot
Methods in org.apache.drill.exec.physical.impl.unpivot with parameters of type ExecutorFragmentContextModifier and TypeMethodDescriptionUnpivotMapsBatchCreator.getBatch(ExecutorFragmentContext context, UnpivotMaps config, List<RecordBatch> children) -
Uses of ExecutorFragmentContext in org.apache.drill.exec.physical.impl.validate
Methods in org.apache.drill.exec.physical.impl.validate with parameters of type ExecutorFragmentContextModifier and TypeMethodDescriptionIteratorValidatorCreator.getBatch(ExecutorFragmentContext context, IteratorValidator config, List<RecordBatch> children) -
Uses of ExecutorFragmentContext in org.apache.drill.exec.physical.impl.values
Methods in org.apache.drill.exec.physical.impl.values with parameters of type ExecutorFragmentContextModifier and TypeMethodDescriptionValuesBatchCreator.getBatch(ExecutorFragmentContext context, Values subScan, List<RecordBatch> children) -
Uses of ExecutorFragmentContext in org.apache.drill.exec.physical.impl.window
Methods in org.apache.drill.exec.physical.impl.window with parameters of type ExecutorFragmentContextModifier and TypeMethodDescriptionWindowFrameBatchCreator.getBatch(ExecutorFragmentContext context, WindowPOP config, List<RecordBatch> children) -
Uses of ExecutorFragmentContext in org.apache.drill.exec.physical.impl.xsort
Methods in org.apache.drill.exec.physical.impl.xsort with parameters of type ExecutorFragmentContextModifier and TypeMethodDescriptionExternalSortBatchCreator.getBatch(ExecutorFragmentContext context, ExternalSort config, List<RecordBatch> children) -
Uses of ExecutorFragmentContext in org.apache.drill.exec.store.delta.read
Methods in org.apache.drill.exec.store.delta.read with parameters of type ExecutorFragmentContextModifier and TypeMethodDescriptionDeltaScanBatchCreator.getBatch(ExecutorFragmentContext context, DeltaRowGroupScan rowGroupScan, List<RecordBatch> children) -
Uses of ExecutorFragmentContext in org.apache.drill.exec.store.dfs.easy
Methods in org.apache.drill.exec.store.dfs.easy with parameters of type ExecutorFragmentContextModifier 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
Methods in org.apache.drill.exec.store.direct with parameters of type ExecutorFragmentContextModifier and TypeMethodDescriptionDirectBatchCreator.getBatch(ExecutorFragmentContext context, DirectSubScan config, List<RecordBatch> children) -
Uses of ExecutorFragmentContext in org.apache.drill.exec.store.drill.plugin
Methods in org.apache.drill.exec.store.drill.plugin with parameters of type ExecutorFragmentContextModifier and TypeMethodDescriptionDrillScanBatchCreator.getBatch(ExecutorFragmentContext context, DrillSubScan subScan, List<RecordBatch> children) Constructors in org.apache.drill.exec.store.drill.plugin with parameters of type ExecutorFragmentContextModifierConstructorDescriptionDrillRecordReader(ExecutorFragmentContext context, DrillSubScan config) -
Uses of ExecutorFragmentContext in org.apache.drill.exec.store.druid
Methods in org.apache.drill.exec.store.druid with parameters of type ExecutorFragmentContextModifier and TypeMethodDescriptionDruidScanBatchCreator.getBatch(ExecutorFragmentContext context, DruidSubScan subScan, List<RecordBatch> children) -
Uses of ExecutorFragmentContext in org.apache.drill.exec.store.enumerable
Methods in org.apache.drill.exec.store.enumerable with parameters of type ExecutorFragmentContextModifier and TypeMethodDescriptionEnumerableBatchCreator.getBatch(ExecutorFragmentContext context, EnumerableSubScan subScan, List<RecordBatch> children) -
Uses of ExecutorFragmentContext in org.apache.drill.exec.store.googlesheets
Methods in org.apache.drill.exec.store.googlesheets with parameters of type ExecutorFragmentContextModifier 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
Methods in org.apache.drill.exec.store.hbase with parameters of type ExecutorFragmentContextModifier and TypeMethodDescriptionHBaseScanBatchCreator.getBatch(ExecutorFragmentContext context, HBaseSubScan subScan, List<RecordBatch> children) -
Uses of ExecutorFragmentContext in org.apache.drill.exec.store.hive
Methods in org.apache.drill.exec.store.hive with parameters of type ExecutorFragmentContextModifier 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
Methods in org.apache.drill.exec.store.hive.readers with parameters of type ExecutorFragmentContextModifier and TypeMethodDescriptionstatic List<RecordReader> ReadersInitializer.init(ExecutorFragmentContext ctx, HiveSubScan config) Selects reader constructor reference asReadersInitializer.HiveReaderFactoryreaderFactory. -
Uses of ExecutorFragmentContext in org.apache.drill.exec.store.http
Methods in org.apache.drill.exec.store.http with parameters of type ExecutorFragmentContextModifier and TypeMethodDescriptionHttpScanBatchCreator.getBatch(ExecutorFragmentContext context, HttpSubScan subScan, List<RecordBatch> children) -
Uses of ExecutorFragmentContext in org.apache.drill.exec.store.iceberg.read
Methods in org.apache.drill.exec.store.iceberg.read with parameters of type ExecutorFragmentContextModifier and TypeMethodDescriptionIcebergScanBatchCreator.getBatch(ExecutorFragmentContext context, IcebergSubScan subScan, List<RecordBatch> children) -
Uses of ExecutorFragmentContext in org.apache.drill.exec.store.ischema
Methods in org.apache.drill.exec.store.ischema with parameters of type ExecutorFragmentContextModifier and TypeMethodDescriptionInfoSchemaBatchCreator.getBatch(ExecutorFragmentContext context, InfoSchemaSubScan config, List<RecordBatch> children) -
Uses of ExecutorFragmentContext in org.apache.drill.exec.store.jdbc
Methods in org.apache.drill.exec.store.jdbc with parameters of type ExecutorFragmentContextModifier 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
Methods in org.apache.drill.exec.store.kafka with parameters of type ExecutorFragmentContextModifier and TypeMethodDescriptionKafkaScanBatchCreator.getBatch(ExecutorFragmentContext context, KafkaSubScan subScan, List<RecordBatch> children) -
Uses of ExecutorFragmentContext in org.apache.drill.exec.store.kudu
Methods in org.apache.drill.exec.store.kudu with parameters of type ExecutorFragmentContextModifier 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
Methods in org.apache.drill.exec.store.mock with parameters of type ExecutorFragmentContextModifier and TypeMethodDescriptionMockScanBatchCreator.getBatch(ExecutorFragmentContext context, MockSubScanPOP config, List<RecordBatch> children) -
Uses of ExecutorFragmentContext in org.apache.drill.exec.store.mongo
Methods in org.apache.drill.exec.store.mongo with parameters of type ExecutorFragmentContextModifier and TypeMethodDescriptionMongoScanBatchCreator.getBatch(ExecutorFragmentContext context, MongoSubScan subScan, List<RecordBatch> children) -
Uses of ExecutorFragmentContext in org.apache.drill.exec.store.openTSDB
Methods in org.apache.drill.exec.store.openTSDB with parameters of type ExecutorFragmentContextModifier and TypeMethodDescriptionOpenTSDBBatchCreator.getBatch(ExecutorFragmentContext context, OpenTSDBSubScan subScan, List<RecordBatch> children) -
Uses of ExecutorFragmentContext in org.apache.drill.exec.store.parquet
Methods in org.apache.drill.exec.store.parquet with parameters of type ExecutorFragmentContextModifier and TypeMethodDescriptionprotected ScanBatchAbstractParquetScanBatchCreator.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
Methods in org.apache.drill.exec.store.phoenix with parameters of type ExecutorFragmentContextModifier and TypeMethodDescriptionPhoenixScanBatchCreator.getBatch(ExecutorFragmentContext context, PhoenixSubScan subScan, List<RecordBatch> children) -
Uses of ExecutorFragmentContext in org.apache.drill.exec.store.splunk
Methods in org.apache.drill.exec.store.splunk with parameters of type ExecutorFragmentContextModifier 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
Methods in org.apache.drill.exec.store.sys with parameters of type ExecutorFragmentContextModifier and TypeMethodDescriptionSystemTableBatchCreator.getBatch(ExecutorFragmentContext context, SystemTableScan scan, List<RecordBatch> children) SystemTable.getIterator(ExecutorFragmentContext context, int maxRecords) Constructors in org.apache.drill.exec.store.sys with parameters of type ExecutorFragmentContextModifierConstructorDescriptionFunctionsIterator(ExecutorFragmentContext context) MemoryIterator(ExecutorFragmentContext context) ProfileInfoIterator(ExecutorFragmentContext context, int maxRecords) protectedProfileIterator(ExecutorFragmentContext context, int maxRecords) ProfileJsonIterator(ExecutorFragmentContext context, int maxRecords) ThreadsIterator(ExecutorFragmentContext context) -
Uses of ExecutorFragmentContext in org.apache.drill.exec.work.filter
Constructors in org.apache.drill.exec.work.filter with parameters of type ExecutorFragmentContext -
Uses of ExecutorFragmentContext in org.apache.drill.exec.work.fragment
Fields in org.apache.drill.exec.work.fragment declared as ExecutorFragmentContextModifier and TypeFieldDescriptionprotected final ExecutorFragmentContextFragmentStatusReporter.contextprotected final ExecutorFragmentContextAbstractFragmentManager.fragmentContextMethods in org.apache.drill.exec.work.fragment that return ExecutorFragmentContextConstructors in org.apache.drill.exec.work.fragment with parameters of type ExecutorFragmentContextModifierConstructorDescriptionFragmentExecutor(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.