Modifier and Type | Field and Description |
---|---|
protected PhysicalOperator |
BaseOperatorContext.popConfig |
Modifier and Type | Method and Description |
---|---|
<T extends PhysicalOperator> |
BaseOperatorContext.getOperatorDefn() |
<T extends PhysicalOperator> |
OperatorContext.getOperatorDefn()
Return the physical operator definition created by the planner and passed
into the Drillbit executing the query.
|
Modifier and Type | Method and Description |
---|---|
static int |
OperatorUtilities.getChildCount(PhysicalOperator popConfig) |
OperatorContext |
FragmentContextInterface.newOperatorContext(PhysicalOperator popConfig) |
OperatorContext |
FragmentContext.newOperatorContext(PhysicalOperator popConfig) |
OperatorContext |
FragmentContextImpl.newOperatorContext(PhysicalOperator popConfig) |
OperatorContext |
FragmentContextInterface.newOperatorContext(PhysicalOperator popConfig,
OperatorStats stats) |
OperatorContext |
FragmentContext.newOperatorContext(PhysicalOperator popConfig,
OperatorStats stats) |
OperatorContext |
FragmentContextImpl.newOperatorContext(PhysicalOperator popConfig,
OperatorStats stats) |
Constructor and Description |
---|
BaseOperatorContext(FragmentContext context,
BufferAllocator allocator,
PhysicalOperator popConfig) |
Modifier and Type | Field and Description |
---|---|
protected Graph<PhysicalOperator,Root,Leaf> |
PhysicalPlan.graph |
Modifier and Type | Method and Description |
---|---|
List<PhysicalOperator> |
PhysicalPlan.getSortedOperators() |
List<PhysicalOperator> |
PhysicalPlan.getSortedOperators(boolean reverse) |
Graph<PhysicalOperator,Root,Leaf> |
PhysicalPlan.graph() |
Constructor and Description |
---|
PhysicalPlan(PlanProperties properties,
List<PhysicalOperator> operators) |
Modifier and Type | Interface and Description |
---|---|
interface |
DbGroupScan
A DbGroupScan operator represents the scan associated with a database.
|
interface |
DbSubScan |
interface |
Exchange |
interface |
FileGroupScan
FileGroupScan operator represents all data which will be scanned from FileSystem by a given physical plan.
|
interface |
FragmentLeaf
A Physical Operator that can be the leaf node of one particular execution
fragment.
|
interface |
FragmentRoot
Describes the root operation within a particular Fragment.
|
interface |
GroupScan
A GroupScan operator represents all data which will be scanned by a given physical
plan.
|
interface |
HasAffinity
Describes a physical operator that has affinity to particular nodes.
|
interface |
IndexGroupScan
An IndexGroupScan operator represents the scan associated with an Index.
|
interface |
Leaf
Operator which specifically is a lowest level leaf node of a query plan
across all possible fragments.
|
interface |
Receiver
A receiver is one half of an exchange operator.
|
interface |
Root
Marker interface describe the root of a query plan.
|
interface |
Scan |
interface |
Sender
A sender is one half of an exchange node operations.
|
interface |
Store
An interface which supports storing a record stream.
|
interface |
SubScan
A SubScan operator represents the data scanned by a particular major/minor
fragment.
|
interface |
Writer
Writer physical operator
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractBase |
class |
AbstractDbGroupScan |
class |
AbstractDbSubScan |
class |
AbstractExchange |
class |
AbstractFileGroupScan |
class |
AbstractGroupScan |
class |
AbstractGroupScanWithMetadata<P extends TableMetadataProvider>
Represents table group scan with metadata usage.
|
class |
AbstractJoinPop |
class |
AbstractMultiple
Describes an operator that expects more than one children operators as its input.
|
class |
AbstractReceiver |
class |
AbstractSender |
class |
AbstractSingle
Describes an operator that expects a single child operator as its input.
|
class |
AbstractStore |
class |
AbstractSubScan |
class |
AbstractWriter |
class |
SchemalessScan
The type of scan operator, which allows to scan schemaless tables (
DynamicDrillTable with null selection) |
Modifier and Type | Field and Description |
---|---|
protected PhysicalOperator |
AbstractSingle.child |
protected PhysicalOperator |
AbstractJoinPop.left |
protected PhysicalOperator |
AbstractJoinPop.right |
Modifier and Type | Field and Description |
---|---|
protected List<PhysicalOperator> |
AbstractMultiple.children |
Modifier and Type | Method and Description |
---|---|
PhysicalOperator |
AbstractSingle.getChild() |
PhysicalOperator |
Exchange.getChild()
Return the feeding child of this operator node.
|
PhysicalOperator |
Store.getChild()
Get the child of this store operator as this will be needed for parallelization materialization purposes.
|
PhysicalOperator |
AbstractJoinPop.getLeft() |
protected abstract PhysicalOperator |
AbstractSingle.getNewWithChild(PhysicalOperator child) |
PhysicalOperator |
AbstractReceiver.getNewWithChildren(List<PhysicalOperator> children) |
PhysicalOperator |
AbstractSingle.getNewWithChildren(List<PhysicalOperator> children) |
PhysicalOperator |
AbstractSubScan.getNewWithChildren(List<PhysicalOperator> children) |
PhysicalOperator |
SchemalessScan.getNewWithChildren(List<PhysicalOperator> children) |
PhysicalOperator |
PhysicalOperator.getNewWithChildren(List<PhysicalOperator> children)
Regenerate with this node with a new set of children.
|
PhysicalOperator |
AbstractJoinPop.getRight() |
Modifier and Type | Method and Description |
---|---|
List<PhysicalOperator> |
AbstractMultiple.getChildren() |
static Set<Class<? extends PhysicalOperator>> |
PhysicalOperatorUtil.getSubTypes(ScanResult classpathScan) |
Iterator<PhysicalOperator> |
AbstractJoinPop.iterator() |
Iterator<PhysicalOperator> |
AbstractMultiple.iterator() |
Iterator<PhysicalOperator> |
AbstractReceiver.iterator() |
Iterator<PhysicalOperator> |
AbstractSingle.iterator() |
Iterator<PhysicalOperator> |
AbstractSubScan.iterator() |
Iterator<PhysicalOperator> |
AbstractGroupScan.iterator() |
Modifier and Type | Method and Description |
---|---|
protected abstract PhysicalOperator |
AbstractSingle.getNewWithChild(PhysicalOperator child) |
Sender |
Exchange.getSender(int minorFragmentId,
PhysicalOperator child)
Get the Sender associated with the given minorFragmentId.
|
Store |
Store.getSpecificStore(PhysicalOperator child,
int minorFragmentId)
Provides full materialized Store operators for execution purposes.
|
T |
AbstractPhysicalVisitor.visitChildren(PhysicalOperator op,
X value) |
RETURN |
PhysicalVisitor.visitOp(PhysicalOperator op,
EXTRA value) |
T |
AbstractPhysicalVisitor.visitOp(PhysicalOperator op,
X value) |
Modifier and Type | Method and Description |
---|---|
void |
AbstractSubScan.accept(GraphVisitor<PhysicalOperator> visitor) |
void |
AbstractBase.accept(GraphVisitor<PhysicalOperator> visitor) |
PhysicalOperator |
AbstractReceiver.getNewWithChildren(List<PhysicalOperator> children) |
PhysicalOperator |
AbstractSingle.getNewWithChildren(List<PhysicalOperator> children) |
PhysicalOperator |
AbstractSubScan.getNewWithChildren(List<PhysicalOperator> children) |
PhysicalOperator |
SchemalessScan.getNewWithChildren(List<PhysicalOperator> children) |
PhysicalOperator |
PhysicalOperator.getNewWithChildren(List<PhysicalOperator> children)
Regenerate with this node with a new set of children.
|
Constructor and Description |
---|
AbstractExchange(PhysicalOperator child) |
AbstractJoinPop(PhysicalOperator leftOp,
PhysicalOperator rightOp,
org.apache.calcite.rel.core.JoinRelType joinType,
boolean semiJoin,
LogicalExpression joinCondition,
List<JoinCondition> joinConditions) |
AbstractSender(int oppositeMajorFragmentId,
PhysicalOperator child,
List<MinorFragmentEndpoint> destinations) |
AbstractSingle(PhysicalOperator child) |
AbstractStore(PhysicalOperator child) |
AbstractWriter(PhysicalOperator child) |
Constructor and Description |
---|
AbstractMultiple(List<PhysicalOperator> children) |
Modifier and Type | Class and Description |
---|---|
class |
AbstractDeMuxExchange
DeMuxExchange is opposite of MuxExchange.
|
class |
AbstractMuxExchange
Multiplexing Exchange (MuxExchange) is used when results from multiple minor fragments belonging to the same
major fragment running on a node need to be collected at one fragment on the same node before distributing the
results further.
|
class |
BroadcastExchange |
class |
BroadcastSender |
class |
ComplexToJson |
class |
ExternalSort |
class |
Filter |
class |
FlattenPOP |
class |
HashAggregate |
class |
HashJoinPOP |
class |
HashPartitionSender |
class |
HashToMergeExchange |
class |
HashToRandomExchange |
class |
IteratorValidator |
class |
LateralJoinPOP |
class |
Limit |
class |
MergeJoinPOP |
class |
MergingReceiverPOP |
class |
MetadataControllerPOP |
class |
MetadataHandlerPOP |
class |
MetadataHashAggPOP |
class |
MetadataStreamAggPOP |
class |
NestedLoopJoinPOP |
class |
OrderedMuxExchange
OrderedMuxExchange is a version of MuxExchange where the incoming batches are sorted
merge operation is performed to produced a sorted stream as output.
|
class |
OrderedPartitionExchange |
class |
OrderedPartitionSender |
class |
PartitionLimit |
class |
ProducerConsumer |
class |
Project |
class |
RangePartitionExchange |
class |
RangePartitionSender |
class |
RowKeyJoinPOP |
class |
RuntimeFilterPOP |
class |
Screen |
class |
SelectionVectorRemover |
class |
SingleMergeExchange |
class |
SingleSender
Sender that pushes all data to a single destination node.
|
class |
Sort |
class |
StatisticsAggregate |
class |
StatisticsMerge |
class |
StreamingAggregate |
class |
TopN |
class |
Trace |
class |
UnionAll |
class |
UnionExchange |
class |
UnnestPOP |
class |
UnorderedDeMuxExchange
UnorderedDeMuxExchange is a version of DeMuxExchange where the incoming batches are not sorted.
|
class |
UnorderedMuxExchange
UnorderedMuxExchange is a version of MuxExchange where the incoming batches are not sorted.
|
class |
UnorderedReceiver |
class |
UnpivotMaps |
class |
Values |
class |
WindowPOP |
Modifier and Type | Method and Description |
---|---|
Iterator<PhysicalOperator> |
FlattenPOP.iterator() |
Iterator<PhysicalOperator> |
MetadataControllerPOP.iterator() |
Iterator<PhysicalOperator> |
RowKeyJoinPOP.iterator() |
Iterator<PhysicalOperator> |
UnnestPOP.iterator() |
Iterator<PhysicalOperator> |
Values.iterator() |
Modifier and Type | Method and Description |
---|---|
PhysicalOperator |
LateralJoinPOP.getNewWithChildren(List<PhysicalOperator> children) |
PhysicalOperator |
MergeJoinPOP.getNewWithChildren(List<PhysicalOperator> children) |
PhysicalOperator |
MetadataControllerPOP.getNewWithChildren(List<PhysicalOperator> children) |
PhysicalOperator |
NestedLoopJoinPOP.getNewWithChildren(List<PhysicalOperator> children) |
PhysicalOperator |
RowKeyJoinPOP.getNewWithChildren(List<PhysicalOperator> children) |
PhysicalOperator |
UnionAll.getNewWithChildren(List<PhysicalOperator> children) |
PhysicalOperator |
UnnestPOP.getNewWithChildren(List<PhysicalOperator> children) |
PhysicalOperator |
HashJoinPOP.getNewWithChildren(List<PhysicalOperator> children) |
PhysicalOperator |
Values.getNewWithChildren(List<PhysicalOperator> children) |
Constructor and Description |
---|
UnionAll(List<PhysicalOperator> children) |
Modifier and Type | Interface and Description |
---|---|
interface |
BatchCreator<T extends PhysicalOperator> |
interface |
RootCreator<T extends PhysicalOperator> |
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.
|
Modifier and Type | Method and Description |
---|---|
RecordBatch |
ImplCreator.getRecordBatch(PhysicalOperator op,
ExecutorFragmentContext context)
Create a RecordBatch and its children for given PhysicalOperator
|
PhysicalOperator |
TraceInjector.visitOp(PhysicalOperator op,
FragmentContext context)
Traverse the physical plan and inject the trace operator after
every operator.
|
Constructor and Description |
---|
BaseRootExec(RootFragmentContext fragmentContext,
OperatorContext oContext,
PhysicalOperator config) |
BaseRootExec(RootFragmentContext fragmentContext,
PhysicalOperator config) |
ScanBatch(PhysicalOperator subScanConfig,
FragmentContext context,
List<RecordReader> readers) |
ScanBatch(PhysicalOperator subScanConfig,
FragmentContext context,
List<RecordReader> readerList,
boolean isRepeatableScan) |
Constructor and Description |
---|
OperatorRecordBatch(FragmentContext context,
PhysicalOperator config,
OperatorExec opExec,
boolean enableSchemaBatch) |
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) |
Constructor and Description |
---|
SpillSet(DrillConfig config,
ExecProtos.FragmentHandle handle,
PhysicalOperator popConfig) |
SpillSet(FragmentContext context,
PhysicalOperator popConfig) |
Modifier and Type | Method and Description |
---|---|
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 |
---|---|
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 |
---|---|
String |
PhysicalPlanReader.writeJson(PhysicalOperator op) |
Modifier and Type | Method and Description |
---|---|
PhysicalOperator |
Fragment.getRoot() |
PhysicalOperator |
Materializer.visitExchange(Exchange exchange,
Materializer.IndexedFragmentNode iNode) |
PhysicalOperator |
Materializer.visitGroupScan(GroupScan groupScan,
Materializer.IndexedFragmentNode iNode) |
PhysicalOperator |
Materializer.visitLateralJoin(LateralJoinPOP op,
Materializer.IndexedFragmentNode iNode) |
PhysicalOperator |
Materializer.visitOp(PhysicalOperator op,
Materializer.IndexedFragmentNode iNode) |
PhysicalOperator |
Materializer.visitRowKeyJoin(RowKeyJoinPOP op,
Materializer.IndexedFragmentNode iNode) |
PhysicalOperator |
Materializer.visitStore(Store store,
Materializer.IndexedFragmentNode iNode) |
PhysicalOperator |
Materializer.visitSubScan(SubScan subScan,
Materializer.IndexedFragmentNode value) |
PhysicalOperator |
Materializer.visitUnnest(UnnestPOP unnest,
Materializer.IndexedFragmentNode value) |
Modifier and Type | Method and Description |
---|---|
List<org.apache.commons.lang3.tuple.Pair<PhysicalOperator,Long>> |
MemoryCalculator.getBufferedOperators(CoordinationProtos.DrillbitEndpoint endpoint) |
List<PhysicalOperator> |
Fragment.getBufferedOperators(QueryContext queryContext) |
protected BiFunction<CoordinationProtos.DrillbitEndpoint,PhysicalOperator,Long> |
DefaultQueryParallelizer.getMemory() |
BiFunction<CoordinationProtos.DrillbitEndpoint,PhysicalOperator,Long> |
QueueQueryParallelizer.getMemory() |
protected abstract BiFunction<CoordinationProtos.DrillbitEndpoint,PhysicalOperator,Long> |
SimpleParallelizer.getMemory() |
Modifier and Type | Method and Description |
---|---|
void |
Materializer.IndexedFragmentNode.addAllocation(PhysicalOperator pop) |
void |
Fragment.addOperator(PhysicalOperator o)
Set the given operator as root operator of this fragment.
|
static List<BitControl.Collector> |
SimpleParallelizer.CountRequiredFragments.getCollectors(PhysicalOperator root,
boolean enableDynamicFC) |
Fragment |
MakeFragmentsVisitor.visitOp(PhysicalOperator op,
Fragment value) |
Void |
SimpleParallelizer.CountRequiredFragments.visitOp(PhysicalOperator op,
List<BitControl.Collector> collectors) |
Void |
Fragment.BufferedOpFinder.visitOp(PhysicalOperator op,
List<PhysicalOperator> value) |
PhysicalOperator |
Materializer.visitOp(PhysicalOperator op,
Materializer.IndexedFragmentNode iNode) |
Void |
StatsCollector.visitOp(PhysicalOperator op,
Wrapper wrapper) |
Void |
MemoryCalculator.visitOp(PhysicalOperator op,
Wrapper fragment) |
Modifier and Type | Method and Description |
---|---|
Void |
Fragment.BufferedOpFinder.visitOp(PhysicalOperator op,
List<PhysicalOperator> value) |
Constructor and Description |
---|
IndexedFragmentNode(int minorFragmentId,
Wrapper info,
BiFunction<Wrapper,Integer,CoordinationProtos.DrillbitEndpoint> wrapperToEndpoint,
BiFunction<CoordinationProtos.DrillbitEndpoint,PhysicalOperator,Long> memoryReqs) |
Modifier and Type | Method and Description |
---|---|
PhysicalOperator |
ExchangeRemoverMaterializer.visitExchange(Exchange exchange,
Materializer.IndexedFragmentNode iNode) |
PhysicalOperator |
ExchangeRemoverMaterializer.visitGroupScan(GroupScan groupScan,
Materializer.IndexedFragmentNode iNode) |
PhysicalOperator |
OperatorIdVisitor.visitOp(PhysicalOperator op,
Integer parentOpId) |
PhysicalOperator |
ExchangeRemoverMaterializer.visitOp(PhysicalOperator op,
Materializer.IndexedFragmentNode iNode) |
PhysicalOperator |
ExchangeRemoverMaterializer.visitStore(Store store,
Materializer.IndexedFragmentNode iNode) |
PhysicalOperator |
OperatorIdVisitor.visitSubScan(SubScan subScan,
Integer parentOpId) |
PhysicalOperator |
ExchangeRemoverMaterializer.visitSubScan(SubScan subScan,
Materializer.IndexedFragmentNode value) |
Modifier and Type | Method and Description |
---|---|
PhysicalOperator |
OperatorIdVisitor.visitOp(PhysicalOperator op,
Integer parentOpId) |
PhysicalOperator |
ExchangeRemoverMaterializer.visitOp(PhysicalOperator op,
Materializer.IndexedFragmentNode iNode) |
Modifier and Type | Method and Description |
---|---|
Writer |
CreateTableEntry.getWriter(PhysicalOperator child) |
Writer |
FileSystemCreateTableEntry.getWriter(PhysicalOperator child) |
Modifier and Type | Method and Description |
---|---|
PhysicalOperator |
PhysicalPlanCreator.addMetadata(Prel originalPrel,
PhysicalOperator op) |
Modifier and Type | Method and Description |
---|---|
protected PhysicalOperator |
DefaultSqlHandler.convertToPop(Prel prel) |
Modifier and Type | Method and Description |
---|---|
static List<PhysicalOperator> |
DefaultSqlHandler.getPops(PhysicalOperator root) |
Modifier and Type | Method and Description |
---|---|
protected PhysicalPlan |
DefaultSqlHandler.convertToPlan(PhysicalOperator op) |
static List<PhysicalOperator> |
DefaultSqlHandler.getPops(PhysicalOperator root) |
Modifier and Type | Class and Description |
---|---|
class |
AbstractBinaryRecordBatch<T extends PhysicalOperator> |
class |
AbstractRecordBatch<T extends PhysicalOperator> |
class |
AbstractSingleRecordBatch<T extends PhysicalOperator>
Implements an AbstractUnaryRecordBatch where the incoming record batch is
known at the time of creation
|
class |
AbstractTableFunctionRecordBatch<T extends PhysicalOperator>
Implements AbstractUnaryRecodBatch for operators that do not have an incoming
record batch available at creation time; the input is typically set up a few
steps after creation.
|
class |
AbstractUnaryRecordBatch<T extends PhysicalOperator>
Base class for operators that have a single input.
|
Modifier and Type | Field and Description |
---|---|
protected T |
AbstractRecordBatch.popConfig |
Modifier and Type | Method and Description |
---|---|
AbstractWriter |
FormatPlugin.getWriter(PhysicalOperator child,
String location,
List<String> partitionColumns) |
Modifier and Type | Class and Description |
---|---|
class |
EasyGroupScan |
class |
EasySubScan |
class |
EasyWriter |
Modifier and Type | Method and Description |
---|---|
protected PhysicalOperator |
EasyWriter.getNewWithChild(PhysicalOperator child) |
PhysicalOperator |
EasyGroupScan.getNewWithChildren(List<PhysicalOperator> children) |
Modifier and Type | Method and Description |
---|---|
protected PhysicalOperator |
EasyWriter.getNewWithChild(PhysicalOperator child) |
AbstractWriter |
EasyFormatPlugin.getWriter(PhysicalOperator child,
String location,
List<String> partitionColumns) |
Modifier and Type | Method and Description |
---|---|
PhysicalOperator |
EasyGroupScan.getNewWithChildren(List<PhysicalOperator> children) |
Constructor and Description |
---|
EasyWriter(PhysicalOperator child,
String location,
List<String> partitionColumns,
EasyFormatPlugin<?> formatPlugin) |
EasyWriter(PhysicalOperator child,
String location,
List<String> partitionColumns,
StorageStrategy storageStrategy,
StoragePluginConfig storageConfig,
FormatPluginConfig formatConfig,
StoragePluginRegistry engineRegistry) |
Modifier and Type | Class and Description |
---|---|
class |
DirectGroupScan |
class |
DirectSubScan |
class |
MetadataDirectGroupScan
Represents direct scan based on metadata information.
|
Modifier and Type | Method and Description |
---|---|
PhysicalOperator |
DirectGroupScan.getNewWithChildren(List<PhysicalOperator> children) |
PhysicalOperator |
MetadataDirectGroupScan.getNewWithChildren(List<PhysicalOperator> children) |
Modifier and Type | Method and Description |
---|---|
PhysicalOperator |
DirectGroupScan.getNewWithChildren(List<PhysicalOperator> children) |
PhysicalOperator |
MetadataDirectGroupScan.getNewWithChildren(List<PhysicalOperator> children) |
Modifier and Type | Class and Description |
---|---|
class |
DruidGroupScan |
class |
DruidSubScan
A Class containing information to read a single druid data source.
|
Modifier and Type | Method and Description |
---|---|
PhysicalOperator |
DruidGroupScan.getNewWithChildren(List<PhysicalOperator> children) |
PhysicalOperator |
DruidSubScan.getNewWithChildren(List<PhysicalOperator> children) |
Modifier and Type | Method and Description |
---|---|
Iterator<PhysicalOperator> |
DruidSubScan.iterator() |
Modifier and Type | Method and Description |
---|---|
PhysicalOperator |
DruidGroupScan.getNewWithChildren(List<PhysicalOperator> children) |
PhysicalOperator |
DruidSubScan.getNewWithChildren(List<PhysicalOperator> children) |
Modifier and Type | Class and Description |
---|---|
class |
EnumerableGroupScan |
class |
EnumerableSubScan |
Modifier and Type | Method and Description |
---|---|
PhysicalOperator |
EnumerableGroupScan.getNewWithChildren(List<PhysicalOperator> children) |
Modifier and Type | Method and Description |
---|---|
PhysicalOperator |
EnumerableGroupScan.getNewWithChildren(List<PhysicalOperator> children) |
Modifier and Type | Method and Description |
---|---|
PhysicalOperator |
EnumerableIntermediatePrel.getPhysicalOperator(PhysicalPlanCreator creator) |
PhysicalOperator |
EnumerablePrel.getPhysicalOperator(PhysicalPlanCreator creator) |
Modifier and Type | Class and Description |
---|---|
class |
HBaseGroupScan |
class |
HBaseSubScan
Information for reading a single HBase region
|
Modifier and Type | Method and Description |
---|---|
PhysicalOperator |
HBaseGroupScan.getNewWithChildren(List<PhysicalOperator> children) |
PhysicalOperator |
HBaseSubScan.getNewWithChildren(List<PhysicalOperator> children) |
Modifier and Type | Method and Description |
---|---|
Iterator<PhysicalOperator> |
HBaseSubScan.iterator() |
Modifier and Type | Method and Description |
---|---|
PhysicalOperator |
HBaseGroupScan.getNewWithChildren(List<PhysicalOperator> children) |
PhysicalOperator |
HBaseSubScan.getNewWithChildren(List<PhysicalOperator> children) |
Modifier and Type | Class and Description |
---|---|
class |
HiveDrillNativeParquetRowGroupScan |
class |
HiveDrillNativeParquetScan |
class |
HiveScan |
class |
HiveSubScan |
Modifier and Type | Method and Description |
---|---|
PhysicalOperator |
HiveDrillNativeParquetRowGroupScan.getNewWithChildren(List<PhysicalOperator> children) |
PhysicalOperator |
HiveDrillNativeParquetScan.getNewWithChildren(List<PhysicalOperator> children) |
PhysicalOperator |
HiveScan.getNewWithChildren(List<PhysicalOperator> children) |
PhysicalOperator |
HiveSubScan.getNewWithChildren(List<PhysicalOperator> children) |
Modifier and Type | Method and Description |
---|---|
Iterator<PhysicalOperator> |
HiveSubScan.iterator() |
Modifier and Type | Method and Description |
---|---|
PhysicalOperator |
HiveDrillNativeParquetRowGroupScan.getNewWithChildren(List<PhysicalOperator> children) |
PhysicalOperator |
HiveDrillNativeParquetScan.getNewWithChildren(List<PhysicalOperator> children) |
PhysicalOperator |
HiveScan.getNewWithChildren(List<PhysicalOperator> children) |
PhysicalOperator |
HiveSubScan.getNewWithChildren(List<PhysicalOperator> children) |
Modifier and Type | Class and Description |
---|---|
class |
HttpGroupScan |
class |
HttpSubScan |
Modifier and Type | Method and Description |
---|---|
PhysicalOperator |
HttpGroupScan.getNewWithChildren(List<PhysicalOperator> children) |
PhysicalOperator |
HttpSubScan.getNewWithChildren(List<PhysicalOperator> children) |
Modifier and Type | Method and Description |
---|---|
Iterator<PhysicalOperator> |
HttpSubScan.iterator() |
Modifier and Type | Method and Description |
---|---|
PhysicalOperator |
HttpGroupScan.getNewWithChildren(List<PhysicalOperator> children) |
PhysicalOperator |
HttpSubScan.getNewWithChildren(List<PhysicalOperator> children) |
Modifier and Type | Class and Description |
---|---|
class |
IcebergGroupScan |
class |
IcebergSubScan |
Modifier and Type | Method and Description |
---|---|
PhysicalOperator |
IcebergGroupScan.getNewWithChildren(List<PhysicalOperator> children) |
PhysicalOperator |
IcebergSubScan.getNewWithChildren(List<PhysicalOperator> children) |
Modifier and Type | Method and Description |
---|---|
Iterator<PhysicalOperator> |
IcebergSubScan.iterator() |
Modifier and Type | Method and Description |
---|---|
PhysicalOperator |
IcebergGroupScan.getNewWithChildren(List<PhysicalOperator> children) |
PhysicalOperator |
IcebergSubScan.getNewWithChildren(List<PhysicalOperator> children) |
Modifier and Type | Method and Description |
---|---|
AbstractWriter |
IcebergFormatPlugin.getWriter(PhysicalOperator child,
String location,
List<String> partitionColumns) |
Modifier and Type | Class and Description |
---|---|
class |
InfoSchemaGroupScan |
class |
InfoSchemaSubScan |
Modifier and Type | Method and Description |
---|---|
PhysicalOperator |
InfoSchemaGroupScan.getNewWithChildren(List<PhysicalOperator> children) |
Modifier and Type | Method and Description |
---|---|
PhysicalOperator |
InfoSchemaGroupScan.getNewWithChildren(List<PhysicalOperator> children) |
Modifier and Type | Class and Description |
---|---|
class |
JdbcGroupScan |
class |
JdbcSubScan |
class |
JdbcWriter |
Modifier and Type | Method and Description |
---|---|
protected PhysicalOperator |
JdbcWriter.getNewWithChild(PhysicalOperator child) |
PhysicalOperator |
JdbcGroupScan.getNewWithChildren(List<PhysicalOperator> children) |
PhysicalOperator |
JdbcIntermediatePrel.getPhysicalOperator(PhysicalPlanCreator creator) |
PhysicalOperator |
JdbcPrel.getPhysicalOperator(PhysicalPlanCreator creator) |
Modifier and Type | Method and Description |
---|---|
protected PhysicalOperator |
JdbcWriter.getNewWithChild(PhysicalOperator child) |
Modifier and Type | Method and Description |
---|---|
PhysicalOperator |
JdbcGroupScan.getNewWithChildren(List<PhysicalOperator> children) |
Constructor and Description |
---|
JdbcWriter(PhysicalOperator child,
String name,
StoragePluginConfig storageConfig,
org.apache.calcite.adapter.jdbc.JdbcSchema inner,
StoragePluginRegistry engineRegistry) |
Modifier and Type | Class and Description |
---|---|
class |
KafkaGroupScan |
class |
KafkaSubScan |
Modifier and Type | Method and Description |
---|---|
PhysicalOperator |
KafkaGroupScan.getNewWithChildren(List<PhysicalOperator> children) |
PhysicalOperator |
KafkaSubScan.getNewWithChildren(List<PhysicalOperator> children) |
Modifier and Type | Method and Description |
---|---|
Iterator<PhysicalOperator> |
KafkaSubScan.iterator() |
Modifier and Type | Method and Description |
---|---|
PhysicalOperator |
KafkaGroupScan.getNewWithChildren(List<PhysicalOperator> children) |
PhysicalOperator |
KafkaSubScan.getNewWithChildren(List<PhysicalOperator> children) |
Modifier and Type | Class and Description |
---|---|
class |
KuduGroupScan |
class |
KuduSubScan
Information for reading a single Kudu tablet
|
class |
KuduWriter |
Modifier and Type | Method and Description |
---|---|
protected PhysicalOperator |
KuduWriter.getNewWithChild(PhysicalOperator child) |
PhysicalOperator |
KuduSubScan.getNewWithChildren(List<PhysicalOperator> children) |
PhysicalOperator |
KuduGroupScan.getNewWithChildren(List<PhysicalOperator> children) |
Modifier and Type | Method and Description |
---|---|
Iterator<PhysicalOperator> |
KuduSubScan.iterator() |
Modifier and Type | Method and Description |
---|---|
protected PhysicalOperator |
KuduWriter.getNewWithChild(PhysicalOperator child) |
Modifier and Type | Method and Description |
---|---|
PhysicalOperator |
KuduSubScan.getNewWithChildren(List<PhysicalOperator> children) |
PhysicalOperator |
KuduGroupScan.getNewWithChildren(List<PhysicalOperator> children) |
Constructor and Description |
---|
KuduWriter(PhysicalOperator child,
String name,
StoragePluginConfig storageConfig,
StoragePluginRegistry engineRegistry) |
Modifier and Type | Method and Description |
---|---|
AbstractWriter |
TableFormatPlugin.getWriter(PhysicalOperator child,
String location,
List<String> partitionColumns) |
Modifier and Type | Class and Description |
---|---|
class |
MapRDBGroupScan |
class |
MapRDBSubScan |
class |
RestrictedMapRDBSubScan
A RestrictedMapRDBSubScan is intended for skip-scan (as opposed to sequential scan) operations
where the set of rowkeys is obtained from a corresponding RowKeyJoin instance
|
Modifier and Type | Method and Description |
---|---|
PhysicalOperator |
MapRDBSubScan.getNewWithChildren(List<PhysicalOperator> children) |
Modifier and Type | Method and Description |
---|---|
Iterator<PhysicalOperator> |
MapRDBSubScan.iterator() |
Modifier and Type | Method and Description |
---|---|
PhysicalOperator |
MapRDBSubScan.getNewWithChildren(List<PhysicalOperator> children) |
Modifier and Type | Class and Description |
---|---|
class |
BinaryTableGroupScan |
Modifier and Type | Method and Description |
---|---|
PhysicalOperator |
BinaryTableGroupScan.getNewWithChildren(List<PhysicalOperator> children) |
Modifier and Type | Method and Description |
---|---|
PhysicalOperator |
BinaryTableGroupScan.getNewWithChildren(List<PhysicalOperator> children) |
Modifier and Type | Class and Description |
---|---|
class |
JsonTableGroupScan |
class |
RestrictedJsonTableGroupScan
A RestrictedJsonTableGroupScan encapsulates (along with a subscan) the functionality
for doing restricted (i.e skip) scan rather than sequential scan.
|
Modifier and Type | Method and Description |
---|---|
PhysicalOperator |
RestrictedJsonTableGroupScan.getNewWithChildren(List<PhysicalOperator> children) |
PhysicalOperator |
JsonTableGroupScan.getNewWithChildren(List<PhysicalOperator> children) |
Modifier and Type | Method and Description |
---|---|
PhysicalOperator |
RestrictedJsonTableGroupScan.getNewWithChildren(List<PhysicalOperator> children) |
PhysicalOperator |
JsonTableGroupScan.getNewWithChildren(List<PhysicalOperator> children) |
Modifier and Type | Method and Description |
---|---|
AbstractWriter |
StreamsFormatPlugin.getWriter(PhysicalOperator child,
String location,
List<String> partitionColumns) |
Modifier and Type | Class and Description |
---|---|
class |
MockGroupScanPOP
Describes a "group" scan of a (logical) mock table.
|
class |
MockStorePOP |
class |
MockSubScanPOP
Describes a physical scan operation for the mock data source.
|
Modifier and Type | Method and Description |
---|---|
protected PhysicalOperator |
MockStorePOP.getNewWithChild(PhysicalOperator child) |
PhysicalOperator |
MockGroupScanPOP.getNewWithChildren(List<PhysicalOperator> children) |
PhysicalOperator |
MockSubScanPOP.getNewWithChildren(List<PhysicalOperator> children) |
Modifier and Type | Method and Description |
---|---|
Iterator<PhysicalOperator> |
MockSubScanPOP.iterator() |
Modifier and Type | Method and Description |
---|---|
protected PhysicalOperator |
MockStorePOP.getNewWithChild(PhysicalOperator child) |
Store |
MockStorePOP.getSpecificStore(PhysicalOperator child,
int minorFragmentId) |
Modifier and Type | Method and Description |
---|---|
PhysicalOperator |
MockGroupScanPOP.getNewWithChildren(List<PhysicalOperator> children) |
PhysicalOperator |
MockSubScanPOP.getNewWithChildren(List<PhysicalOperator> children) |
Constructor and Description |
---|
MockStorePOP(PhysicalOperator child) |
Modifier and Type | Class and Description |
---|---|
class |
MongoGroupScan |
class |
MongoSubScan |
Modifier and Type | Method and Description |
---|---|
PhysicalOperator |
MongoSubScan.getNewWithChildren(List<PhysicalOperator> children) |
PhysicalOperator |
MongoGroupScan.getNewWithChildren(List<PhysicalOperator> children) |
Modifier and Type | Method and Description |
---|---|
Iterator<PhysicalOperator> |
MongoSubScan.iterator() |
Modifier and Type | Method and Description |
---|---|
PhysicalOperator |
MongoSubScan.getNewWithChildren(List<PhysicalOperator> children) |
PhysicalOperator |
MongoGroupScan.getNewWithChildren(List<PhysicalOperator> children) |
Modifier and Type | Class and Description |
---|---|
class |
OpenTSDBGroupScan |
class |
OpenTSDBSubScan |
Modifier and Type | Method and Description |
---|---|
PhysicalOperator |
OpenTSDBSubScan.getNewWithChildren(List<PhysicalOperator> children) |
PhysicalOperator |
OpenTSDBGroupScan.getNewWithChildren(List<PhysicalOperator> children) |
Modifier and Type | Method and Description |
---|---|
Iterator<PhysicalOperator> |
OpenTSDBSubScan.iterator() |
Modifier and Type | Method and Description |
---|---|
PhysicalOperator |
OpenTSDBSubScan.getNewWithChildren(List<PhysicalOperator> children) |
PhysicalOperator |
OpenTSDBGroupScan.getNewWithChildren(List<PhysicalOperator> children) |
Modifier and Type | Class and Description |
---|---|
class |
AbstractParquetGroupScan |
class |
AbstractParquetRowGroupScan |
class |
ParquetGroupScan |
class |
ParquetRowGroupScan |
class |
ParquetWriter |
Modifier and Type | Method and Description |
---|---|
protected PhysicalOperator |
ParquetWriter.getNewWithChild(PhysicalOperator child) |
PhysicalOperator |
ParquetRowGroupScan.getNewWithChildren(List<PhysicalOperator> children) |
PhysicalOperator |
ParquetGroupScan.getNewWithChildren(List<PhysicalOperator> children) |
Modifier and Type | Method and Description |
---|---|
Iterator<PhysicalOperator> |
AbstractParquetRowGroupScan.iterator() |
Modifier and Type | Method and Description |
---|---|
protected PhysicalOperator |
ParquetWriter.getNewWithChild(PhysicalOperator child) |
AbstractWriter |
ParquetFormatPlugin.getWriter(PhysicalOperator child,
String location,
List<String> partitionColumns) |
Modifier and Type | Method and Description |
---|---|
PhysicalOperator |
ParquetRowGroupScan.getNewWithChildren(List<PhysicalOperator> children) |
PhysicalOperator |
ParquetGroupScan.getNewWithChildren(List<PhysicalOperator> children) |
Constructor and Description |
---|
ParquetWriter(PhysicalOperator child,
String location,
List<String> partitionColumns,
ParquetFormatPlugin formatPlugin) |
ParquetWriter(PhysicalOperator child,
String location,
List<String> partitionColumns,
StorageStrategy storageStrategy,
StoragePluginConfig storageConfig,
StoragePluginRegistry engineRegistry) |
Modifier and Type | Class and Description |
---|---|
class |
PhoenixGroupScan |
class |
PhoenixSubScan |
Modifier and Type | Method and Description |
---|---|
PhysicalOperator |
PhoenixGroupScan.getNewWithChildren(List<PhysicalOperator> children) |
PhysicalOperator |
PhoenixSubScan.getNewWithChildren(List<PhysicalOperator> children) |
Modifier and Type | Method and Description |
---|---|
Iterator<PhysicalOperator> |
PhoenixSubScan.iterator() |
Modifier and Type | Method and Description |
---|---|
PhysicalOperator |
PhoenixGroupScan.getNewWithChildren(List<PhysicalOperator> children) |
PhysicalOperator |
PhoenixSubScan.getNewWithChildren(List<PhysicalOperator> children) |
Modifier and Type | Method and Description |
---|---|
PhysicalOperator |
PhoenixIntermediatePrel.getPhysicalOperator(PhysicalPlanCreator creator) |
PhysicalOperator |
PhoenixPrel.getPhysicalOperator(PhysicalPlanCreator creator) |
Modifier and Type | Method and Description |
---|---|
PhysicalOperator |
PluginIntermediatePrel.getPhysicalOperator(PhysicalPlanCreator creator) |
PhysicalOperator |
PluginPrel.getPhysicalOperator(PhysicalPlanCreator creator) |
Modifier and Type | Class and Description |
---|---|
class |
SplunkGroupScan |
class |
SplunkSubScan |
Modifier and Type | Method and Description |
---|---|
PhysicalOperator |
SplunkGroupScan.getNewWithChildren(List<PhysicalOperator> children) |
PhysicalOperator |
SplunkSubScan.getNewWithChildren(List<PhysicalOperator> children) |
Modifier and Type | Method and Description |
---|---|
Iterator<PhysicalOperator> |
SplunkSubScan.iterator() |
Modifier and Type | Method and Description |
---|---|
PhysicalOperator |
SplunkGroupScan.getNewWithChildren(List<PhysicalOperator> children) |
PhysicalOperator |
SplunkSubScan.getNewWithChildren(List<PhysicalOperator> children) |
Modifier and Type | Class and Description |
---|---|
class |
SystemTableScan |
Modifier and Type | Method and Description |
---|---|
PhysicalOperator |
SystemTableScan.getNewWithChildren(List<PhysicalOperator> children) |
Modifier and Type | Method and Description |
---|---|
PhysicalOperator |
SystemTableScan.getNewWithChildren(List<PhysicalOperator> children) |
Modifier and Type | Method and Description |
---|---|
static List<PhysicalOperator> |
MemoryAllocationUtilities.getBufferedOperators(List<PhysicalOperator> operators,
QueryContext queryContext) |
Modifier and Type | Method and Description |
---|---|
static List<PhysicalOperator> |
MemoryAllocationUtilities.getBufferedOperators(List<PhysicalOperator> operators,
QueryContext queryContext) |
static void |
MemoryAllocationUtilities.setupBufferedOpsMemoryAllocations(boolean planHasMemory,
List<PhysicalOperator> bufferedOperators,
QueryContext queryContext)
Helper method to setup Memory Allocations
|
Modifier and Type | Method and Description |
---|---|
Void |
RuntimeFilterRouter.RuntimeFilterParallelismCollector.visitOp(PhysicalOperator op,
org.apache.drill.exec.work.filter.RuntimeFilterRouter.RFHelperHolder holder) |
Modifier and Type | Method and Description |
---|---|
Void |
ThrottledResourceManager.QueuedResourceAllocator.BufferedOpFinder.visitOp(PhysicalOperator op,
List<PhysicalOperator> value) |
Modifier and Type | Method and Description |
---|---|
Void |
ThrottledResourceManager.QueuedResourceAllocator.BufferedOpFinder.visitOp(PhysicalOperator op,
List<PhysicalOperator> value) |
Copyright © 1970 The Apache Software Foundation. All rights reserved.