Uses of Interface
org.apache.drill.exec.physical.base.PhysicalOperator
Package
Description
Defines a revised implementation of the Drill RecordBatch protocol.
Provides run-time semantic analysis of the projection list for the
scan operator.
Provides the "version 3" scan framework (which can also be thought of
as EVF version 2).
Collection of classes shared by operators that implement spill-to-disk.
Drill storage plugin.
Kafka storage plugin.
Defines a mock data source which generates dummy test data for use
in testing.
MongoDB storage plugin.
Provides resource management and queuing support for the Drill foreman.
-
Uses of PhysicalOperator in org.apache.drill.exec.ops
Modifier and TypeMethodDescription<T extends PhysicalOperator>
TBaseOperatorContext.getOperatorDefn()
<T extends PhysicalOperator>
TOperatorContext.getOperatorDefn()
Return the physical operator definition created by the planner and passed into the Drillbit executing the query.Modifier and TypeMethodDescriptionstatic int
OperatorUtilities.getChildCount
(PhysicalOperator popConfig) FragmentContext.newOperatorContext
(PhysicalOperator popConfig) FragmentContext.newOperatorContext
(PhysicalOperator popConfig, OperatorStats stats) FragmentContextImpl.newOperatorContext
(PhysicalOperator popConfig) FragmentContextImpl.newOperatorContext
(PhysicalOperator popConfig, OperatorStats stats) FragmentContextInterface.newOperatorContext
(PhysicalOperator popConfig) FragmentContextInterface.newOperatorContext
(PhysicalOperator popConfig, OperatorStats stats) ModifierConstructorDescriptionBaseOperatorContext
(FragmentContext context, BufferAllocator allocator, PhysicalOperator popConfig) -
Uses of PhysicalOperator in org.apache.drill.exec.physical
Modifier and TypeMethodDescriptionPhysicalPlan.getSortedOperators()
PhysicalPlan.getSortedOperators
(boolean reverse) PhysicalPlan.graph()
ModifierConstructorDescriptionPhysicalPlan
(PlanProperties properties, List<PhysicalOperator> operators) -
Uses of PhysicalOperator in org.apache.drill.exec.physical.base
Modifier and TypeInterfaceDescriptioninterface
A DbGroupScan operator represents the scan associated with a database.interface
interface
interface
FileGroupScan operator represents all data which will be scanned from FileSystem by a given physical plan.interface
A Physical Operator that can be the leaf node of one particular execution fragment.interface
Describes the root operation within a particular Fragment.interface
A GroupScan operator represents all data which will be scanned by a given physical plan.interface
Describes a physical operator that has affinity to particular nodes.interface
An IndexGroupScan operator represents the scan associated with an Index.interface
Operator which specifically is a lowest level leaf node of a query plan across all possible fragments.interface
A receiver is one half of an exchange operator.interface
Marker interface describe the root of a query plan.interface
interface
A sender is one half of an exchange node operations.interface
An interface which supports storing a record stream.interface
A SubScan operator represents the data scanned by a particular major/minor fragment.interface
Writer physical operatorModifier and TypeClassDescriptionclass
class
class
class
class
class
class
Represents table group scan with metadata usage.class
class
Describes an operator that expects more than one children operators as its input.class
class
class
Describes an operator that expects a single child operator as its input.class
class
class
class
The type of scan operator, which allows to scan schemaless tables (DynamicDrillTable
with null selection)Modifier and TypeFieldDescriptionprotected final PhysicalOperator
AbstractSingle.child
protected final PhysicalOperator
AbstractJoinPop.left
protected final PhysicalOperator
AbstractJoinPop.right
Modifier and TypeFieldDescriptionprotected final List<PhysicalOperator>
AbstractMultiple.children
Modifier and TypeMethodDescriptionAbstractSingle.getChild()
Exchange.getChild()
Return the feeding child of this operator node.Store.getChild()
Get the child of this store operator as this will be needed for parallelization materialization purposes.AbstractJoinPop.getLeft()
protected abstract PhysicalOperator
AbstractSingle.getNewWithChild
(PhysicalOperator child) final PhysicalOperator
AbstractReceiver.getNewWithChildren
(List<PhysicalOperator> children) final PhysicalOperator
AbstractSingle.getNewWithChildren
(List<PhysicalOperator> children) AbstractSubScan.getNewWithChildren
(List<PhysicalOperator> children) PhysicalOperator.getNewWithChildren
(List<PhysicalOperator> children) Regenerate with this node with a new set of children.SchemalessScan.getNewWithChildren
(List<PhysicalOperator> children) AbstractJoinPop.getRight()
Modifier and TypeMethodDescriptionAbstractMultiple.getChildren()
static Set<Class<? extends PhysicalOperator>>
PhysicalOperatorUtil.getSubTypes
(ScanResult classpathScan) AbstractGroupScan.iterator()
AbstractJoinPop.iterator()
AbstractMultiple.iterator()
AbstractReceiver.iterator()
AbstractSingle.iterator()
AbstractSubScan.iterator()
Modifier and TypeMethodDescriptionprotected abstract PhysicalOperator
AbstractSingle.getNewWithChild
(PhysicalOperator child) Exchange.getSender
(int minorFragmentId, PhysicalOperator child) Get the Sender associated with the given minorFragmentId.Store.getSpecificStore
(PhysicalOperator child, int minorFragmentId) Provides full materialized Store operators for execution purposes.AbstractPhysicalVisitor.visitChildren
(PhysicalOperator op, X value) AbstractPhysicalVisitor.visitOp
(PhysicalOperator op, X value) PhysicalVisitor.visitOp
(PhysicalOperator op, EXTRA value) Modifier and TypeMethodDescriptionvoid
AbstractBase.accept
(GraphVisitor<PhysicalOperator> visitor) void
AbstractSubScan.accept
(GraphVisitor<PhysicalOperator> visitor) final PhysicalOperator
AbstractReceiver.getNewWithChildren
(List<PhysicalOperator> children) final PhysicalOperator
AbstractSingle.getNewWithChildren
(List<PhysicalOperator> children) AbstractSubScan.getNewWithChildren
(List<PhysicalOperator> children) PhysicalOperator.getNewWithChildren
(List<PhysicalOperator> children) Regenerate with this node with a new set of children.SchemalessScan.getNewWithChildren
(List<PhysicalOperator> children) ModifierConstructorDescriptionAbstractExchange
(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) -
Uses of PhysicalOperator in org.apache.drill.exec.physical.config
Modifier and TypeClassDescriptionclass
DeMuxExchange is opposite of MuxExchange.class
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
class
class
class
class
class
class
class
class
class
class
class
class
class
class
class
class
class
class
class
class
class
OrderedMuxExchange is a version of MuxExchange where the incoming batches are sorted merge operation is performed to produced a sorted stream as output.class
class
class
class
class
class
class
class
class
class
class
class
class
class
Sender that pushes all data to a single destination node.class
class
class
class
class
class
class
class
class
class
class
UnorderedDeMuxExchange is a version of DeMuxExchange where the incoming batches are not sorted.class
UnorderedMuxExchange is a version of MuxExchange where the incoming batches are not sorted.class
class
class
class
Modifier and TypeMethodDescriptionMetadataControllerPOP.getLeft()
RowKeyJoinPOP.getLeft()
protected PhysicalOperator
BroadcastExchange.getNewWithChild
(PhysicalOperator child) protected PhysicalOperator
BroadcastSender.getNewWithChild
(PhysicalOperator child) protected PhysicalOperator
ComplexToJson.getNewWithChild
(PhysicalOperator child) protected PhysicalOperator
ExternalSort.getNewWithChild
(PhysicalOperator child) protected PhysicalOperator
Filter.getNewWithChild
(PhysicalOperator child) protected PhysicalOperator
FlattenPOP.getNewWithChild
(PhysicalOperator child) protected PhysicalOperator
HashAggregate.getNewWithChild
(PhysicalOperator child) protected PhysicalOperator
HashPartitionSender.getNewWithChild
(PhysicalOperator child) protected PhysicalOperator
HashToMergeExchange.getNewWithChild
(PhysicalOperator child) protected PhysicalOperator
HashToRandomExchange.getNewWithChild
(PhysicalOperator child) protected PhysicalOperator
IteratorValidator.getNewWithChild
(PhysicalOperator child) protected PhysicalOperator
Limit.getNewWithChild
(PhysicalOperator child) protected PhysicalOperator
MetadataHandlerPOP.getNewWithChild
(PhysicalOperator child) protected PhysicalOperator
MetadataHashAggPOP.getNewWithChild
(PhysicalOperator child) protected PhysicalOperator
MetadataStreamAggPOP.getNewWithChild
(PhysicalOperator child) protected PhysicalOperator
OrderedMuxExchange.getNewWithChild
(PhysicalOperator child) protected PhysicalOperator
OrderedPartitionExchange.getNewWithChild
(PhysicalOperator child) protected PhysicalOperator
OrderedPartitionSender.getNewWithChild
(PhysicalOperator child) protected PhysicalOperator
PartitionLimit.getNewWithChild
(PhysicalOperator child) protected PhysicalOperator
ProducerConsumer.getNewWithChild
(PhysicalOperator child) protected PhysicalOperator
Project.getNewWithChild
(PhysicalOperator child) protected PhysicalOperator
RangePartitionExchange.getNewWithChild
(PhysicalOperator child) protected PhysicalOperator
RangePartitionSender.getNewWithChild
(PhysicalOperator child) protected PhysicalOperator
RuntimeFilterPOP.getNewWithChild
(PhysicalOperator child) protected PhysicalOperator
Screen.getNewWithChild
(PhysicalOperator child) protected PhysicalOperator
SelectionVectorRemover.getNewWithChild
(PhysicalOperator child) protected PhysicalOperator
SingleMergeExchange.getNewWithChild
(PhysicalOperator child) protected PhysicalOperator
SingleSender.getNewWithChild
(PhysicalOperator child) protected PhysicalOperator
Sort.getNewWithChild
(PhysicalOperator child) protected PhysicalOperator
StatisticsAggregate.getNewWithChild
(PhysicalOperator child) protected PhysicalOperator
StatisticsMerge.getNewWithChild
(PhysicalOperator child) protected PhysicalOperator
StreamingAggregate.getNewWithChild
(PhysicalOperator child) protected PhysicalOperator
TableModify.getNewWithChild
(PhysicalOperator child) protected PhysicalOperator
TopN.getNewWithChild
(PhysicalOperator child) protected PhysicalOperator
Trace.getNewWithChild
(PhysicalOperator child) protected PhysicalOperator
UnionExchange.getNewWithChild
(PhysicalOperator child) protected PhysicalOperator
UnorderedDeMuxExchange.getNewWithChild
(PhysicalOperator child) protected PhysicalOperator
UnorderedMuxExchange.getNewWithChild
(PhysicalOperator child) protected PhysicalOperator
UnpivotMaps.getNewWithChild
(PhysicalOperator child) protected PhysicalOperator
WindowPOP.getNewWithChild
(PhysicalOperator child) HashJoinPOP.getNewWithChildren
(List<PhysicalOperator> children) LateralJoinPOP.getNewWithChildren
(List<PhysicalOperator> children) MergeJoinPOP.getNewWithChildren
(List<PhysicalOperator> children) MetadataControllerPOP.getNewWithChildren
(List<PhysicalOperator> children) NestedLoopJoinPOP.getNewWithChildren
(List<PhysicalOperator> children) RowKeyJoinPOP.getNewWithChildren
(List<PhysicalOperator> children) SetOp.getNewWithChildren
(List<PhysicalOperator> children) UnionAll.getNewWithChildren
(List<PhysicalOperator> children) UnnestPOP.getNewWithChildren
(List<PhysicalOperator> children) Values.getNewWithChildren
(List<PhysicalOperator> children) MetadataControllerPOP.getRight()
RowKeyJoinPOP.getRight()
Modifier and TypeMethodDescriptionFlattenPOP.iterator()
MetadataControllerPOP.iterator()
RowKeyJoinPOP.iterator()
UnnestPOP.iterator()
Values.iterator()
Modifier and TypeMethodDescriptionprotected PhysicalOperator
BroadcastExchange.getNewWithChild
(PhysicalOperator child) protected PhysicalOperator
BroadcastSender.getNewWithChild
(PhysicalOperator child) protected PhysicalOperator
ComplexToJson.getNewWithChild
(PhysicalOperator child) protected PhysicalOperator
ExternalSort.getNewWithChild
(PhysicalOperator child) protected PhysicalOperator
Filter.getNewWithChild
(PhysicalOperator child) protected PhysicalOperator
FlattenPOP.getNewWithChild
(PhysicalOperator child) protected PhysicalOperator
HashAggregate.getNewWithChild
(PhysicalOperator child) protected PhysicalOperator
HashPartitionSender.getNewWithChild
(PhysicalOperator child) protected PhysicalOperator
HashToMergeExchange.getNewWithChild
(PhysicalOperator child) protected PhysicalOperator
HashToRandomExchange.getNewWithChild
(PhysicalOperator child) protected PhysicalOperator
IteratorValidator.getNewWithChild
(PhysicalOperator child) protected PhysicalOperator
Limit.getNewWithChild
(PhysicalOperator child) protected PhysicalOperator
MetadataHandlerPOP.getNewWithChild
(PhysicalOperator child) protected PhysicalOperator
MetadataHashAggPOP.getNewWithChild
(PhysicalOperator child) protected PhysicalOperator
MetadataStreamAggPOP.getNewWithChild
(PhysicalOperator child) protected PhysicalOperator
OrderedMuxExchange.getNewWithChild
(PhysicalOperator child) protected PhysicalOperator
OrderedPartitionExchange.getNewWithChild
(PhysicalOperator child) protected PhysicalOperator
OrderedPartitionSender.getNewWithChild
(PhysicalOperator child) protected PhysicalOperator
PartitionLimit.getNewWithChild
(PhysicalOperator child) protected PhysicalOperator
ProducerConsumer.getNewWithChild
(PhysicalOperator child) protected PhysicalOperator
Project.getNewWithChild
(PhysicalOperator child) protected PhysicalOperator
RangePartitionExchange.getNewWithChild
(PhysicalOperator child) protected PhysicalOperator
RangePartitionSender.getNewWithChild
(PhysicalOperator child) protected PhysicalOperator
RuntimeFilterPOP.getNewWithChild
(PhysicalOperator child) protected PhysicalOperator
Screen.getNewWithChild
(PhysicalOperator child) protected PhysicalOperator
SelectionVectorRemover.getNewWithChild
(PhysicalOperator child) protected PhysicalOperator
SingleMergeExchange.getNewWithChild
(PhysicalOperator child) protected PhysicalOperator
SingleSender.getNewWithChild
(PhysicalOperator child) protected PhysicalOperator
Sort.getNewWithChild
(PhysicalOperator child) protected PhysicalOperator
StatisticsAggregate.getNewWithChild
(PhysicalOperator child) protected PhysicalOperator
StatisticsMerge.getNewWithChild
(PhysicalOperator child) protected PhysicalOperator
StreamingAggregate.getNewWithChild
(PhysicalOperator child) protected PhysicalOperator
TableModify.getNewWithChild
(PhysicalOperator child) protected PhysicalOperator
TopN.getNewWithChild
(PhysicalOperator child) protected PhysicalOperator
Trace.getNewWithChild
(PhysicalOperator child) protected PhysicalOperator
UnionExchange.getNewWithChild
(PhysicalOperator child) protected PhysicalOperator
UnorderedDeMuxExchange.getNewWithChild
(PhysicalOperator child) protected PhysicalOperator
UnorderedMuxExchange.getNewWithChild
(PhysicalOperator child) protected PhysicalOperator
UnpivotMaps.getNewWithChild
(PhysicalOperator child) protected PhysicalOperator
WindowPOP.getNewWithChild
(PhysicalOperator child) AbstractDeMuxExchange.getSender
(int minorFragmentId, PhysicalOperator child) AbstractMuxExchange.getSender
(int minorFragmentId, PhysicalOperator child) BroadcastExchange.getSender
(int minorFragmentId, PhysicalOperator child) HashToMergeExchange.getSender
(int minorFragmentId, PhysicalOperator child) HashToRandomExchange.getSender
(int minorFragmentId, PhysicalOperator child) OrderedPartitionExchange.getSender
(int minorFragmentId, PhysicalOperator child) RangePartitionExchange.getSender
(int minorFragmentId, PhysicalOperator child) SingleMergeExchange.getSender
(int minorFragmentId, PhysicalOperator child) UnionExchange.getSender
(int minorFragmentId, PhysicalOperator child) Screen.getSpecificStore
(PhysicalOperator child, int minorFragmentId) Modifier and TypeMethodDescriptionHashJoinPOP.getNewWithChildren
(List<PhysicalOperator> children) LateralJoinPOP.getNewWithChildren
(List<PhysicalOperator> children) MergeJoinPOP.getNewWithChildren
(List<PhysicalOperator> children) MetadataControllerPOP.getNewWithChildren
(List<PhysicalOperator> children) NestedLoopJoinPOP.getNewWithChildren
(List<PhysicalOperator> children) RowKeyJoinPOP.getNewWithChildren
(List<PhysicalOperator> children) SetOp.getNewWithChildren
(List<PhysicalOperator> children) UnionAll.getNewWithChildren
(List<PhysicalOperator> children) UnnestPOP.getNewWithChildren
(List<PhysicalOperator> children) Values.getNewWithChildren
(List<PhysicalOperator> children) ModifierConstructorDescriptionAbstractDeMuxExchange
(PhysicalOperator child, LogicalExpression expr) BroadcastSender
(int oppositeMajorFragmentId, PhysicalOperator child, List<MinorFragmentEndpoint> destinations) ComplexToJson
(PhysicalOperator child) ExternalSort
(PhysicalOperator child, List<Order.Ordering> orderings, boolean reverse) Filter
(PhysicalOperator child, LogicalExpression expr, float selectivity) FlattenPOP
(PhysicalOperator child, SchemaPath column) HashAggregate
(PhysicalOperator child, AggPrelBase.OperatorPhase aggPhase, List<NamedExpression> groupByExprs, List<NamedExpression> aggrExprs, float cardinality) HashJoinPOP
(PhysicalOperator left, PhysicalOperator right, List<JoinCondition> conditions, org.apache.calcite.rel.core.JoinRelType joinType) HashJoinPOP
(PhysicalOperator left, PhysicalOperator right, List<JoinCondition> conditions, org.apache.calcite.rel.core.JoinRelType joinType, boolean semiJoin, RuntimeFilterDef runtimeFilterDef, boolean isRowKeyJoin, int joinControl) HashJoinPOP
(PhysicalOperator left, PhysicalOperator right, List<JoinCondition> conditions, org.apache.calcite.rel.core.JoinRelType joinType, RuntimeFilterDef runtimeFilterDef) HashJoinPOP
(PhysicalOperator left, PhysicalOperator right, List<JoinCondition> conditions, org.apache.calcite.rel.core.JoinRelType joinType, RuntimeFilterDef runtimeFilterDef, boolean isRowKeyJoin, int joinControl) HashPartitionSender
(int oppositeMajorFragmentId, PhysicalOperator child, LogicalExpression expr, List<MinorFragmentEndpoint> endpoints) HashPartitionSender
(int oppositeMajorFragmentId, PhysicalOperator child, LogicalExpression expr, List<MinorFragmentEndpoint> endpoints, int outgoingBatchSize) HashToMergeExchange
(PhysicalOperator child, LogicalExpression expr, List<Order.Ordering> orderExprs) HashToRandomExchange
(PhysicalOperator child, LogicalExpression expr) IteratorValidator
(PhysicalOperator child, boolean repeatable) LateralJoinPOP
(PhysicalOperator left, PhysicalOperator right, org.apache.calcite.rel.core.JoinRelType joinType, String implicitRIDColumn, List<SchemaPath> excludedColumns) Limit
(PhysicalOperator child, Integer first, Integer last) MergeJoinPOP
(PhysicalOperator left, PhysicalOperator right, List<JoinCondition> conditions, org.apache.calcite.rel.core.JoinRelType joinType) MetadataControllerPOP
(PhysicalOperator left, PhysicalOperator right, MetadataControllerContext context) MetadataHandlerPOP
(PhysicalOperator child, MetadataHandlerContext context) MetadataHashAggPOP
(PhysicalOperator child, MetadataAggregateContext context, AggPrelBase.OperatorPhase phase) MetadataStreamAggPOP
(PhysicalOperator child, MetadataAggregateContext context, AggPrelBase.OperatorPhase phase) NestedLoopJoinPOP
(PhysicalOperator left, PhysicalOperator right, org.apache.calcite.rel.core.JoinRelType joinType, LogicalExpression condition) OrderedMuxExchange
(PhysicalOperator child, List<Order.Ordering> orderings) OrderedPartitionExchange
(List<Order.Ordering> orderings, FieldReference ref, PhysicalOperator child, Integer recordsToSample, Integer samplingFactor, Float completionFactor) OrderedPartitionSender
(List<Order.Ordering> orderings, FieldReference ref, PhysicalOperator child, List<MinorFragmentEndpoint> endpoints, int oppositeMajorFragmentId, int sendingWidth, int recordsToSample, int samplingFactor, float completionFactor) PartitionLimit
(PhysicalOperator child, Integer first, Integer last, String partitionColumn) ProducerConsumer
(PhysicalOperator child, int size) Project
(List<NamedExpression> exprs, PhysicalOperator child) Project
(List<NamedExpression> exprs, PhysicalOperator child, boolean outputProj) RangePartitionExchange
(PhysicalOperator child, PartitionFunction partitionFunction) RangePartitionSender
(int oppositeMajorFragmentId, PhysicalOperator child, List<MinorFragmentEndpoint> endpoints, PartitionFunction partitionFunction) RowKeyJoinPOP
(PhysicalOperator left, PhysicalOperator right) RuntimeFilterPOP
(PhysicalOperator child, long identifier) Screen
(PhysicalOperator child, CoordinationProtos.DrillbitEndpoint endpoint) SingleMergeExchange
(PhysicalOperator child, List<Order.Ordering> orderExpr) SingleSender
(int oppositeMajorFragmentId, int oppositeMinorFragmentId, PhysicalOperator child, CoordinationProtos.DrillbitEndpoint destination) Create a SingleSender which sends data to fragment identified by given MajorFragmentId and MinorFragmentId, and running at given endpointSingleSender
(int oppositeMajorFragmentId, PhysicalOperator child, CoordinationProtos.DrillbitEndpoint destination) Create a SingleSender which sends data to fragment with MinorFragmentId as 0 in given opposite major fragment.Sort
(PhysicalOperator child, List<Order.Ordering> orderings, boolean reverse) StatisticsAggregate
(PhysicalOperator child, List<String> functions) StatisticsMerge
(PhysicalOperator child, Map<String, String> functions, double samplePercent) StreamingAggregate
(PhysicalOperator child, List<NamedExpression> keys, List<NamedExpression> exprs) TableModify
(PhysicalOperator child) TopN
(PhysicalOperator child, List<Order.Ordering> orderings, boolean reverse, int limit) Trace
(PhysicalOperator child, String traceTag) UnionExchange
(PhysicalOperator child) UnnestPOP
(PhysicalOperator child, SchemaPath column, String implicitColumn) UnorderedDeMuxExchange
(PhysicalOperator child, LogicalExpression expr) UnpivotMaps
(PhysicalOperator child, List<String> mapFieldNames) WindowPOP
(PhysicalOperator child, List<NamedExpression> withins, List<NamedExpression> aggregations, List<Order.Ordering> orderings, boolean frameUnitsRows, WindowPOP.Bound start, WindowPOP.Bound end) ModifierConstructorDescriptionSetOp
(List<PhysicalOperator> children, org.apache.calcite.sql.SqlKind kind, boolean all) UnionAll
(List<PhysicalOperator> children) -
Uses of PhysicalOperator in org.apache.drill.exec.physical.impl
Modifier and TypeInterfaceDescriptioninterface
BatchCreator<T extends PhysicalOperator>
interface
RootCreator<T extends PhysicalOperator>
Modifier and TypeMethodDescriptionstatic PhysicalOperator
TraceInjector.getExec
(FragmentContext context, FragmentRoot root) TraceInjector.visitOp
(PhysicalOperator op, FragmentContext context) Traverse the physical plan and inject the trace operator after every operator.Modifier and TypeMethodDescriptionImplCreator.getRecordBatch
(PhysicalOperator op, ExecutorFragmentContext context) Create a RecordBatch and its children for given PhysicalOperatorTraceInjector.visitOp
(PhysicalOperator op, FragmentContext context) Traverse the physical plan and inject the trace operator after every operator.ModifierConstructorDescriptionBaseRootExec
(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) -
Uses of PhysicalOperator in org.apache.drill.exec.physical.impl.join
Modifier and TypeClassDescriptionclass
AbstractHashBinaryRecordBatch<T extends PhysicalOperator>
Base class for the runtime execution implementation of the Hash-Join and Hash-SetOp operatorclass
ProbeTemplate<T extends PhysicalOperator>
-
Uses of PhysicalOperator in org.apache.drill.exec.physical.impl.protocol
ModifierConstructorDescriptionOperatorRecordBatch
(FragmentContext context, PhysicalOperator config, OperatorExec opExec, boolean enableSchemaBatch) -
Uses of PhysicalOperator in org.apache.drill.exec.physical.impl.scan.project
Modifier and TypeMethodDescriptionScanSchemaOrchestrator.ScanOrchestratorBuilder.buildScanOperator
(FragmentContext fragContext, PhysicalOperator pop) -
Uses of PhysicalOperator in org.apache.drill.exec.physical.impl.scan.v3
Modifier and TypeMethodDescriptionScanLifecycleBuilder.buildScanOperator
(FragmentContext fragContext, PhysicalOperator pop) -
Uses of PhysicalOperator in org.apache.drill.exec.physical.impl.spill
ModifierConstructorDescriptionSpillSet
(DrillConfig config, ExecProtos.FragmentHandle handle, PhysicalOperator popConfig) SpillSet
(FragmentContext context, PhysicalOperator popConfig) -
Uses of PhysicalOperator in org.apache.drill.exec.physical.impl.validate
Modifier and TypeMethodDescriptionIteratorValidatorInjector.visitOp
(PhysicalOperator op, FragmentContext context) Traverse the physical plan and inject the IteratorValidator operator after every operator.Modifier and TypeMethodDescriptionIteratorValidatorInjector.visitOp
(PhysicalOperator op, FragmentContext context) Traverse the physical plan and inject the IteratorValidator operator after every operator. -
Uses of PhysicalOperator in org.apache.drill.exec.planner
-
Uses of PhysicalOperator in org.apache.drill.exec.planner.fragment
Modifier and TypeMethodDescriptionFragment.getRoot()
Materializer.visitExchange
(Exchange exchange, Materializer.IndexedFragmentNode iNode) Materializer.visitGroupScan
(GroupScan groupScan, Materializer.IndexedFragmentNode iNode) Materializer.visitLateralJoin
(LateralJoinPOP op, Materializer.IndexedFragmentNode iNode) Materializer.visitOp
(PhysicalOperator op, Materializer.IndexedFragmentNode iNode) Materializer.visitRowKeyJoin
(RowKeyJoinPOP op, Materializer.IndexedFragmentNode iNode) Materializer.visitStore
(Store store, Materializer.IndexedFragmentNode iNode) Materializer.visitSubScan
(SubScan subScan, Materializer.IndexedFragmentNode value) Materializer.visitUnnest
(UnnestPOP unnest, Materializer.IndexedFragmentNode value) Modifier and TypeMethodDescriptionFragment.getBufferedOperators
(QueryContext queryContext) List<org.apache.commons.lang3.tuple.Pair<PhysicalOperator,
Long>> MemoryCalculator.getBufferedOperators
(CoordinationProtos.DrillbitEndpoint endpoint) DefaultQueryParallelizer.getMemory()
QueueQueryParallelizer.getMemory()
protected abstract BiFunction<CoordinationProtos.DrillbitEndpoint,
PhysicalOperator, Long> SimpleParallelizer.getMemory()
Modifier and TypeMethodDescriptionvoid
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.BufferedOpFinder.visitOp
(PhysicalOperator op, List<PhysicalOperator> value) MakeFragmentsVisitor.visitOp
(PhysicalOperator op, Fragment value) Materializer.visitOp
(PhysicalOperator op, Materializer.IndexedFragmentNode iNode) MemoryCalculator.visitOp
(PhysicalOperator op, Wrapper fragment) SimpleParallelizer.CountRequiredFragments.visitOp
(PhysicalOperator op, List<BitControl.Collector> collectors) StatsCollector.visitOp
(PhysicalOperator op, Wrapper wrapper) Modifier and TypeMethodDescriptionFragment.BufferedOpFinder.visitOp
(PhysicalOperator op, List<PhysicalOperator> value) -
Uses of PhysicalOperator in org.apache.drill.exec.planner.fragment.contrib
Modifier and TypeMethodDescriptionExchangeRemoverMaterializer.visitExchange
(Exchange exchange, Materializer.IndexedFragmentNode iNode) ExchangeRemoverMaterializer.visitGroupScan
(GroupScan groupScan, Materializer.IndexedFragmentNode iNode) ExchangeRemoverMaterializer.visitOp
(PhysicalOperator op, Materializer.IndexedFragmentNode iNode) OperatorIdVisitor.visitOp
(PhysicalOperator op, Integer parentOpId) ExchangeRemoverMaterializer.visitStore
(Store store, Materializer.IndexedFragmentNode iNode) ExchangeRemoverMaterializer.visitSubScan
(SubScan subScan, Materializer.IndexedFragmentNode value) OperatorIdVisitor.visitSubScan
(SubScan subScan, Integer parentOpId) Modifier and TypeMethodDescriptionExchangeRemoverMaterializer.visitOp
(PhysicalOperator op, Materializer.IndexedFragmentNode iNode) OperatorIdVisitor.visitOp
(PhysicalOperator op, Integer parentOpId) -
Uses of PhysicalOperator in org.apache.drill.exec.planner.logical
Modifier and TypeMethodDescriptionCreateTableEntry.getWriter
(PhysicalOperator child) FileSystemCreateTableEntry.getWriter
(PhysicalOperator child) ModifyTableEntry.getWriter
(PhysicalOperator child) -
Uses of PhysicalOperator in org.apache.drill.exec.planner.physical
Modifier and TypeMethodDescriptionPhysicalPlanCreator.addMetadata
(Prel originalPrel, PhysicalOperator op) BroadcastExchangePrel.getPhysicalOperator
(PhysicalPlanCreator creator) ComplexToJsonPrel.getPhysicalOperator
(PhysicalPlanCreator creator) DirectScanPrel.getPhysicalOperator
(PhysicalPlanCreator creator) FilterPrel.getPhysicalOperator
(PhysicalPlanCreator creator) FlattenPrel.getPhysicalOperator
(PhysicalPlanCreator creator) HashAggPrel.getPhysicalOperator
(PhysicalPlanCreator creator) HashJoinPrel.getPhysicalOperator
(PhysicalPlanCreator creator) HashToMergeExchangePrel.getPhysicalOperator
(PhysicalPlanCreator creator) HashToRandomExchangePrel.getPhysicalOperator
(PhysicalPlanCreator creator) LateralJoinPrel.getPhysicalOperator
(PhysicalPlanCreator creator) LimitPrel.getPhysicalOperator
(PhysicalPlanCreator creator) MergeJoinPrel.getPhysicalOperator
(PhysicalPlanCreator creator) MetadataControllerPrel.getPhysicalOperator
(PhysicalPlanCreator creator) MetadataHandlerPrel.getPhysicalOperator
(PhysicalPlanCreator creator) MetadataHashAggPrel.getPhysicalOperator
(PhysicalPlanCreator creator) MetadataStreamAggPrel.getPhysicalOperator
(PhysicalPlanCreator creator) NestedLoopJoinPrel.getPhysicalOperator
(PhysicalPlanCreator creator) OrderedMuxExchangePrel.getPhysicalOperator
(PhysicalPlanCreator creator) OrderedPartitionExchangePrel.getPhysicalOperator
(PhysicalPlanCreator creator) Prel.getPhysicalOperator
(PhysicalPlanCreator creator) ProducerConsumerPrel.getPhysicalOperator
(PhysicalPlanCreator creator) ProjectAllowDupPrel.getPhysicalOperator
(PhysicalPlanCreator creator) ProjectPrel.getPhysicalOperator
(PhysicalPlanCreator creator) RangePartitionExchangePrel.getPhysicalOperator
(PhysicalPlanCreator creator) RowKeyJoinPrel.getPhysicalOperator
(PhysicalPlanCreator creator) RuntimeFilterPrel.getPhysicalOperator
(PhysicalPlanCreator creator) ScanPrel.getPhysicalOperator
(PhysicalPlanCreator creator) ScreenPrel.getPhysicalOperator
(PhysicalPlanCreator creator) SelectionVectorRemoverPrel.getPhysicalOperator
(PhysicalPlanCreator creator) SetOpPrel.getPhysicalOperator
(PhysicalPlanCreator creator) SingleMergeExchangePrel.getPhysicalOperator
(PhysicalPlanCreator creator) SortPrel.getPhysicalOperator
(PhysicalPlanCreator creator) StatsAggPrel.getPhysicalOperator
(PhysicalPlanCreator creator) StatsMergePrel.getPhysicalOperator
(PhysicalPlanCreator creator) StreamAggPrel.getPhysicalOperator
(PhysicalPlanCreator creator) TableModifyPrel.getPhysicalOperator
(PhysicalPlanCreator creator) TopNPrel.getPhysicalOperator
(PhysicalPlanCreator creator) UnionAllPrel.getPhysicalOperator
(PhysicalPlanCreator creator) UnionDistinctPrel.getPhysicalOperator
(PhysicalPlanCreator creator) UnionExchangePrel.getPhysicalOperator
(PhysicalPlanCreator creator) UnnestPrel.getPhysicalOperator
(PhysicalPlanCreator creator) UnorderedDeMuxExchangePrel.getPhysicalOperator
(PhysicalPlanCreator creator) UnorderedMuxExchangePrel.getPhysicalOperator
(PhysicalPlanCreator creator) UnpivotMapsPrel.getPhysicalOperator
(PhysicalPlanCreator creator) ValuesPrel.getPhysicalOperator
(PhysicalPlanCreator creator) WindowPrel.getPhysicalOperator
(PhysicalPlanCreator creator) WriterPrel.getPhysicalOperator
(PhysicalPlanCreator creator) Modifier and TypeMethodDescriptionPhysicalPlanCreator.addMetadata
(Prel originalPrel, PhysicalOperator op) -
Uses of PhysicalOperator in org.apache.drill.exec.planner.sql.handlers
Modifier and TypeMethodDescriptionprotected PhysicalOperator
DefaultSqlHandler.convertToPop
(Prel prel) Modifier and TypeMethodDescriptionstatic List<PhysicalOperator>
DefaultSqlHandler.getPops
(PhysicalOperator root) Modifier and TypeMethodDescriptionprotected PhysicalPlan
DefaultSqlHandler.convertToPlan
(PhysicalOperator op, org.apache.calcite.rel.RelNode queryRelNode) static List<PhysicalOperator>
DefaultSqlHandler.getPops
(PhysicalOperator root) -
Uses of PhysicalOperator in org.apache.drill.exec.record
Modifier and TypeClassDescriptionclass
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 creationclass
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. -
Uses of PhysicalOperator in org.apache.drill.exec.store.delta
Modifier and TypeMethodDescriptionDeltaGroupScan.getNewWithChildren
(List<PhysicalOperator> children) DeltaRowGroupScan.getNewWithChildren
(List<PhysicalOperator> children) Modifier and TypeMethodDescriptionDeltaGroupScan.getNewWithChildren
(List<PhysicalOperator> children) DeltaRowGroupScan.getNewWithChildren
(List<PhysicalOperator> children) -
Uses of PhysicalOperator in org.apache.drill.exec.store.delta.format
Modifier and TypeMethodDescriptionDeltaFormatPlugin.getWriter
(PhysicalOperator child, String location, List<String> partitionColumns) -
Uses of PhysicalOperator in org.apache.drill.exec.store.dfs
Modifier and TypeMethodDescriptionFormatPlugin.getWriter
(PhysicalOperator child, String location, List<String> partitionColumns) -
Uses of PhysicalOperator in org.apache.drill.exec.store.dfs.easy
Modifier and TypeMethodDescriptionprotected PhysicalOperator
EasyWriter.getNewWithChild
(PhysicalOperator child) EasyGroupScan.getNewWithChildren
(List<PhysicalOperator> children) Modifier and TypeMethodDescriptionprotected PhysicalOperator
EasyWriter.getNewWithChild
(PhysicalOperator child) EasyFormatPlugin.getWriter
(PhysicalOperator child, String location, List<String> partitionColumns) Modifier and TypeMethodDescriptionEasyGroupScan.getNewWithChildren
(List<PhysicalOperator> children) ModifierConstructorDescriptionEasyWriter
(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) -
Uses of PhysicalOperator in org.apache.drill.exec.store.direct
Modifier and TypeClassDescriptionclass
class
class
Represents direct scan based on metadata information.Modifier and TypeMethodDescriptionDirectGroupScan.getNewWithChildren
(List<PhysicalOperator> children) MetadataDirectGroupScan.getNewWithChildren
(List<PhysicalOperator> children) Modifier and TypeMethodDescriptionDirectGroupScan.getNewWithChildren
(List<PhysicalOperator> children) MetadataDirectGroupScan.getNewWithChildren
(List<PhysicalOperator> children) -
Uses of PhysicalOperator in org.apache.drill.exec.store.drill.plugin
Modifier and TypeMethodDescriptionDrillGroupScan.getNewWithChildren
(List<PhysicalOperator> children) DrillSubScan.getNewWithChildren
(List<PhysicalOperator> children) Modifier and TypeMethodDescriptionDrillGroupScan.getNewWithChildren
(List<PhysicalOperator> children) DrillSubScan.getNewWithChildren
(List<PhysicalOperator> children) -
Uses of PhysicalOperator in org.apache.drill.exec.store.druid
Modifier and TypeClassDescriptionclass
class
A Class containing information to read a single druid data source.Modifier and TypeMethodDescriptionDruidGroupScan.getNewWithChildren
(List<PhysicalOperator> children) DruidSubScan.getNewWithChildren
(List<PhysicalOperator> children) Modifier and TypeMethodDescriptionDruidGroupScan.getNewWithChildren
(List<PhysicalOperator> children) DruidSubScan.getNewWithChildren
(List<PhysicalOperator> children) -
Uses of PhysicalOperator in org.apache.drill.exec.store.enumerable
Modifier and TypeMethodDescriptionEnumerableGroupScan.getNewWithChildren
(List<PhysicalOperator> children) Modifier and TypeMethodDescriptionEnumerableGroupScan.getNewWithChildren
(List<PhysicalOperator> children) -
Uses of PhysicalOperator in org.apache.drill.exec.store.enumerable.plan
Modifier and TypeMethodDescriptionEnumerableIntermediatePrel.getPhysicalOperator
(PhysicalPlanCreator creator) EnumerablePrel.getPhysicalOperator
(PhysicalPlanCreator creator) -
Uses of PhysicalOperator in org.apache.drill.exec.store.googlesheets
Modifier and TypeClassDescriptionclass
class
class
class
Modifier and TypeMethodDescriptionprotected PhysicalOperator
GoogleSheetsInsertWriter.getNewWithChild
(PhysicalOperator child) protected PhysicalOperator
GoogleSheetsWriter.getNewWithChild
(PhysicalOperator child) GoogleSheetsGroupScan.getNewWithChildren
(List<PhysicalOperator> children) Modifier and TypeMethodDescriptionprotected PhysicalOperator
GoogleSheetsInsertWriter.getNewWithChild
(PhysicalOperator child) protected PhysicalOperator
GoogleSheetsWriter.getNewWithChild
(PhysicalOperator child) Modifier and TypeMethodDescriptionGoogleSheetsGroupScan.getNewWithChildren
(List<PhysicalOperator> children) ModifierConstructorDescriptionGoogleSheetsInsertWriter
(PhysicalOperator child, String sheetName, String name, String queryUser, GoogleSheetsStoragePlugin plugin) GoogleSheetsInsertWriter
(PhysicalOperator child, String sheetName, String name, StoragePluginConfig storageConfig, String queryUser, StoragePluginRegistry engineRegistry) GoogleSheetsWriter
(PhysicalOperator child, String sheetName, String name, String queryUser, GoogleSheetsStoragePlugin plugin) GoogleSheetsWriter
(PhysicalOperator child, String sheetName, String name, StoragePluginConfig storageConfig, String queryUser, StoragePluginRegistry engineRegistry) -
Uses of PhysicalOperator in org.apache.drill.exec.store.hbase
Modifier and TypeClassDescriptionclass
class
Information for reading a single HBase regionModifier and TypeMethodDescriptionHBaseGroupScan.getNewWithChildren
(List<PhysicalOperator> children) HBaseSubScan.getNewWithChildren
(List<PhysicalOperator> children) Modifier and TypeMethodDescriptionHBaseGroupScan.getNewWithChildren
(List<PhysicalOperator> children) HBaseSubScan.getNewWithChildren
(List<PhysicalOperator> children) -
Uses of PhysicalOperator in org.apache.drill.exec.store.hive
Modifier and TypeClassDescriptionclass
class
class
class
Modifier and TypeMethodDescriptionHiveDrillNativeParquetRowGroupScan.getNewWithChildren
(List<PhysicalOperator> children) HiveDrillNativeParquetScan.getNewWithChildren
(List<PhysicalOperator> children) HiveScan.getNewWithChildren
(List<PhysicalOperator> children) HiveSubScan.getNewWithChildren
(List<PhysicalOperator> children) Modifier and TypeMethodDescriptionHiveDrillNativeParquetRowGroupScan.getNewWithChildren
(List<PhysicalOperator> children) HiveDrillNativeParquetScan.getNewWithChildren
(List<PhysicalOperator> children) HiveScan.getNewWithChildren
(List<PhysicalOperator> children) HiveSubScan.getNewWithChildren
(List<PhysicalOperator> children) -
Uses of PhysicalOperator in org.apache.drill.exec.store.http
Modifier and TypeMethodDescriptionHttpGroupScan.getNewWithChildren
(List<PhysicalOperator> children) HttpSubScan.getNewWithChildren
(List<PhysicalOperator> children) Modifier and TypeMethodDescriptionHttpGroupScan.getNewWithChildren
(List<PhysicalOperator> children) HttpSubScan.getNewWithChildren
(List<PhysicalOperator> children) -
Uses of PhysicalOperator in org.apache.drill.exec.store.iceberg
Modifier and TypeMethodDescriptionIcebergGroupScan.getNewWithChildren
(List<PhysicalOperator> children) IcebergSubScan.getNewWithChildren
(List<PhysicalOperator> children) Modifier and TypeMethodDescriptionIcebergGroupScan.getNewWithChildren
(List<PhysicalOperator> children) IcebergSubScan.getNewWithChildren
(List<PhysicalOperator> children) -
Uses of PhysicalOperator in org.apache.drill.exec.store.iceberg.format
Modifier and TypeMethodDescriptionIcebergFormatPlugin.getWriter
(PhysicalOperator child, String location, List<String> partitionColumns) -
Uses of PhysicalOperator in org.apache.drill.exec.store.ischema
Modifier and TypeMethodDescriptionInfoSchemaGroupScan.getNewWithChildren
(List<PhysicalOperator> children) Modifier and TypeMethodDescriptionInfoSchemaGroupScan.getNewWithChildren
(List<PhysicalOperator> children) -
Uses of PhysicalOperator in org.apache.drill.exec.store.jdbc
Modifier and TypeClassDescriptionclass
class
class
class
Modifier and TypeMethodDescriptionprotected PhysicalOperator
JdbcInsertWriter.getNewWithChild
(PhysicalOperator child) protected PhysicalOperator
JdbcWriter.getNewWithChild
(PhysicalOperator child) JdbcGroupScan.getNewWithChildren
(List<PhysicalOperator> children) JdbcIntermediatePrel.getPhysicalOperator
(PhysicalPlanCreator creator) JdbcPrel.getPhysicalOperator
(PhysicalPlanCreator creator) Modifier and TypeMethodDescriptionprotected PhysicalOperator
JdbcInsertWriter.getNewWithChild
(PhysicalOperator child) protected PhysicalOperator
JdbcWriter.getNewWithChild
(PhysicalOperator child) Modifier and TypeMethodDescriptionJdbcGroupScan.getNewWithChildren
(List<PhysicalOperator> children) ModifierConstructorDescriptionJdbcInsertWriter
(PhysicalOperator child, List<String> tableIdentifier, StoragePluginConfig storageConfig, org.apache.calcite.adapter.jdbc.JdbcSchema inner, StoragePluginRegistry engineRegistry) JdbcWriter
(PhysicalOperator child, List<String> tableIdentifier, StoragePluginConfig storageConfig, org.apache.calcite.adapter.jdbc.JdbcSchema inner, StoragePluginRegistry engineRegistry) -
Uses of PhysicalOperator in org.apache.drill.exec.store.kafka
Modifier and TypeMethodDescriptionKafkaGroupScan.getNewWithChildren
(List<PhysicalOperator> children) KafkaSubScan.getNewWithChildren
(List<PhysicalOperator> children) Modifier and TypeMethodDescriptionKafkaGroupScan.getNewWithChildren
(List<PhysicalOperator> children) KafkaSubScan.getNewWithChildren
(List<PhysicalOperator> children) -
Uses of PhysicalOperator in org.apache.drill.exec.store.kudu
Modifier and TypeClassDescriptionclass
class
Information for reading a single Kudu tabletclass
Modifier and TypeMethodDescriptionprotected PhysicalOperator
KuduWriter.getNewWithChild
(PhysicalOperator child) KuduGroupScan.getNewWithChildren
(List<PhysicalOperator> children) KuduSubScan.getNewWithChildren
(List<PhysicalOperator> children) Modifier and TypeMethodDescriptionprotected PhysicalOperator
KuduWriter.getNewWithChild
(PhysicalOperator child) Modifier and TypeMethodDescriptionKuduGroupScan.getNewWithChildren
(List<PhysicalOperator> children) KuduSubScan.getNewWithChildren
(List<PhysicalOperator> children) ModifierConstructorDescriptionKuduWriter
(PhysicalOperator child, String name, StoragePluginConfig storageConfig, StoragePluginRegistry engineRegistry) -
Uses of PhysicalOperator in org.apache.drill.exec.store.mock
Modifier and TypeClassDescriptionclass
Describes a "group" scan of a (logical) mock table.class
class
Describes a physical scan operation for the mock data source.Modifier and TypeMethodDescriptionprotected PhysicalOperator
MockStorePOP.getNewWithChild
(PhysicalOperator child) MockGroupScanPOP.getNewWithChildren
(List<PhysicalOperator> children) MockSubScanPOP.getNewWithChildren
(List<PhysicalOperator> children) Modifier and TypeMethodDescriptionprotected PhysicalOperator
MockStorePOP.getNewWithChild
(PhysicalOperator child) MockStorePOP.getSpecificStore
(PhysicalOperator child, int minorFragmentId) Modifier and TypeMethodDescriptionMockGroupScanPOP.getNewWithChildren
(List<PhysicalOperator> children) MockSubScanPOP.getNewWithChildren
(List<PhysicalOperator> children) -
Uses of PhysicalOperator in org.apache.drill.exec.store.mongo
Modifier and TypeMethodDescriptionMongoGroupScan.getNewWithChildren
(List<PhysicalOperator> children) MongoSubScan.getNewWithChildren
(List<PhysicalOperator> children) Modifier and TypeMethodDescriptionMongoGroupScan.getNewWithChildren
(List<PhysicalOperator> children) MongoSubScan.getNewWithChildren
(List<PhysicalOperator> children) -
Uses of PhysicalOperator in org.apache.drill.exec.store.openTSDB
Modifier and TypeMethodDescriptionOpenTSDBGroupScan.getNewWithChildren
(List<PhysicalOperator> children) OpenTSDBSubScan.getNewWithChildren
(List<PhysicalOperator> children) Modifier and TypeMethodDescriptionOpenTSDBGroupScan.getNewWithChildren
(List<PhysicalOperator> children) OpenTSDBSubScan.getNewWithChildren
(List<PhysicalOperator> children) -
Uses of PhysicalOperator in org.apache.drill.exec.store.parquet
Modifier and TypeClassDescriptionclass
class
class
class
class
Modifier and TypeMethodDescriptionprotected PhysicalOperator
ParquetWriter.getNewWithChild
(PhysicalOperator child) ParquetGroupScan.getNewWithChildren
(List<PhysicalOperator> children) ParquetRowGroupScan.getNewWithChildren
(List<PhysicalOperator> children) Modifier and TypeMethodDescriptionprotected PhysicalOperator
ParquetWriter.getNewWithChild
(PhysicalOperator child) ParquetFormatPlugin.getWriter
(PhysicalOperator child, String location, List<String> partitionColumns) Modifier and TypeMethodDescriptionParquetGroupScan.getNewWithChildren
(List<PhysicalOperator> children) ParquetRowGroupScan.getNewWithChildren
(List<PhysicalOperator> children) ModifierConstructorDescriptionParquetWriter
(PhysicalOperator child, String location, List<String> partitionColumns, ParquetFormatPlugin formatPlugin) ParquetWriter
(PhysicalOperator child, String location, List<String> partitionColumns, StorageStrategy storageStrategy, StoragePluginConfig storageConfig, StoragePluginRegistry engineRegistry) -
Uses of PhysicalOperator in org.apache.drill.exec.store.phoenix
Modifier and TypeMethodDescriptionPhoenixGroupScan.getNewWithChildren
(List<PhysicalOperator> children) PhoenixSubScan.getNewWithChildren
(List<PhysicalOperator> children) Modifier and TypeMethodDescriptionPhoenixGroupScan.getNewWithChildren
(List<PhysicalOperator> children) PhoenixSubScan.getNewWithChildren
(List<PhysicalOperator> children) -
Uses of PhysicalOperator in org.apache.drill.exec.store.phoenix.rules
Modifier and TypeMethodDescriptionPhoenixIntermediatePrel.getPhysicalOperator
(PhysicalPlanCreator creator) PhoenixPrel.getPhysicalOperator
(PhysicalPlanCreator creator) -
Uses of PhysicalOperator in org.apache.drill.exec.store.plan.rel
Modifier and TypeMethodDescriptionPluginIntermediatePrel.getPhysicalOperator
(PhysicalPlanCreator creator) PluginPrel.getPhysicalOperator
(PhysicalPlanCreator creator) -
Uses of PhysicalOperator in org.apache.drill.exec.store.splunk
Modifier and TypeClassDescriptionclass
class
class
class
Modifier and TypeMethodDescriptionprotected PhysicalOperator
SplunkInsertWriter.getNewWithChild
(PhysicalOperator child) protected PhysicalOperator
SplunkWriter.getNewWithChild
(PhysicalOperator child) SplunkGroupScan.getNewWithChildren
(List<PhysicalOperator> children) SplunkSubScan.getNewWithChildren
(List<PhysicalOperator> children) Modifier and TypeMethodDescriptionprotected PhysicalOperator
SplunkInsertWriter.getNewWithChild
(PhysicalOperator child) protected PhysicalOperator
SplunkWriter.getNewWithChild
(PhysicalOperator child) Modifier and TypeMethodDescriptionSplunkGroupScan.getNewWithChildren
(List<PhysicalOperator> children) SplunkSubScan.getNewWithChildren
(List<PhysicalOperator> children) ModifierConstructorDescriptionSplunkInsertWriter
(PhysicalOperator child, List<String> tableIdentifier, SplunkPluginConfig storageConfig, StoragePluginRegistry pluginRegistry) SplunkWriter
(PhysicalOperator child, List<String> tableIdentifier, SplunkPluginConfig storageConfig, StoragePluginRegistry engineRegistry) -
Uses of PhysicalOperator in org.apache.drill.exec.store.sys
Modifier and TypeMethodDescriptionSystemTableScan.getNewWithChildren
(List<PhysicalOperator> children) Modifier and TypeMethodDescriptionSystemTableScan.getNewWithChildren
(List<PhysicalOperator> children) -
Uses of PhysicalOperator in org.apache.drill.exec.util
Modifier and TypeMethodDescriptionstatic List<PhysicalOperator>
MemoryAllocationUtilities.getBufferedOperators
(List<PhysicalOperator> operators, QueryContext queryContext) Modifier and TypeMethodDescriptionstatic 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 -
Uses of PhysicalOperator in org.apache.drill.exec.work.filter
Modifier and TypeMethodDescriptionRuntimeFilterRouter.RuntimeFilterParallelismCollector.visitOp
(PhysicalOperator op, org.apache.drill.exec.work.filter.RuntimeFilterRouter.RFHelperHolder holder) -
Uses of PhysicalOperator in org.apache.drill.exec.work.foreman.rm
Modifier and TypeMethodDescriptionThrottledResourceManager.QueuedResourceAllocator.BufferedOpFinder.visitOp
(PhysicalOperator op, List<PhysicalOperator> value) Modifier and TypeMethodDescriptionThrottledResourceManager.QueuedResourceAllocator.BufferedOpFinder.visitOp
(PhysicalOperator op, List<PhysicalOperator> value)