Uses of Interface
org.apache.drill.exec.physical.base.PhysicalOperator
Packages that use 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
Fields in org.apache.drill.exec.ops declared as PhysicalOperatorMethods in org.apache.drill.exec.ops with type parameters of type PhysicalOperatorModifier 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.Methods in org.apache.drill.exec.ops with parameters of type PhysicalOperatorModifier and TypeMethodDescriptionstatic intOperatorUtilities.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) Constructors in org.apache.drill.exec.ops with parameters of type PhysicalOperatorModifierConstructorDescriptionBaseOperatorContext(FragmentContext context, BufferAllocator allocator, PhysicalOperator popConfig) -
Uses of PhysicalOperator in org.apache.drill.exec.physical
Fields in org.apache.drill.exec.physical with type parameters of type PhysicalOperatorMethods in org.apache.drill.exec.physical that return types with arguments of type PhysicalOperatorModifier and TypeMethodDescriptionPhysicalPlan.getSortedOperators()PhysicalPlan.getSortedOperators(boolean reverse) PhysicalPlan.graph()Constructor parameters in org.apache.drill.exec.physical with type arguments of type PhysicalOperatorModifierConstructorDescriptionPhysicalPlan(PlanProperties properties, List<PhysicalOperator> operators) -
Uses of PhysicalOperator in org.apache.drill.exec.physical.base
Subinterfaces of PhysicalOperator in org.apache.drill.exec.physical.baseModifier and TypeInterfaceDescriptioninterfaceA DbGroupScan operator represents the scan associated with a database.interfaceinterfaceinterfaceFileGroupScan operator represents all data which will be scanned from FileSystem by a given physical plan.interfaceA Physical Operator that can be the leaf node of one particular execution fragment.interfaceDescribes the root operation within a particular Fragment.interfaceA GroupScan operator represents all data which will be scanned by a given physical plan.interfaceDescribes a physical operator that has affinity to particular nodes.interfaceAn IndexGroupScan operator represents the scan associated with an Index.interfaceOperator which specifically is a lowest level leaf node of a query plan across all possible fragments.interfaceA receiver is one half of an exchange operator.interfaceMarker interface describe the root of a query plan.interfaceinterfaceA sender is one half of an exchange node operations.interfaceAn interface which supports storing a record stream.interfaceA SubScan operator represents the data scanned by a particular major/minor fragment.interfaceWriter physical operatorClasses in org.apache.drill.exec.physical.base that implement PhysicalOperatorModifier and TypeClassDescriptionclassclassclassclassclassclassclassRepresents table group scan with metadata usage.classclassDescribes an operator that expects more than one children operators as its input.classclassclassDescribes an operator that expects a single child operator as its input.classclassclassclassThe type of scan operator, which allows to scan schemaless tables (DynamicDrillTablewith null selection)Fields in org.apache.drill.exec.physical.base declared as PhysicalOperatorModifier and TypeFieldDescriptionprotected final PhysicalOperatorAbstractSingle.childprotected final PhysicalOperatorAbstractJoinPop.leftprotected final PhysicalOperatorAbstractJoinPop.rightFields in org.apache.drill.exec.physical.base with type parameters of type PhysicalOperatorModifier and TypeFieldDescriptionprotected final List<PhysicalOperator> AbstractMultiple.childrenMethods in org.apache.drill.exec.physical.base that return PhysicalOperatorModifier 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 PhysicalOperatorAbstractSingle.getNewWithChild(PhysicalOperator child) final PhysicalOperatorAbstractReceiver.getNewWithChildren(List<PhysicalOperator> children) final PhysicalOperatorAbstractSingle.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()Methods in org.apache.drill.exec.physical.base that return types with arguments of type PhysicalOperatorModifier and TypeMethodDescriptionAbstractMultiple.getChildren()static Set<Class<? extends PhysicalOperator>> PhysicalOperatorUtil.getSubTypes(ScanResult classpathScan) AbstractGroupScan.iterator()AbstractJoinPop.iterator()AbstractMultiple.iterator()AbstractReceiver.iterator()AbstractSingle.iterator()AbstractSubScan.iterator()Methods in org.apache.drill.exec.physical.base with parameters of type PhysicalOperatorModifier and TypeMethodDescriptionprotected abstract PhysicalOperatorAbstractSingle.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) Method parameters in org.apache.drill.exec.physical.base with type arguments of type PhysicalOperatorModifier and TypeMethodDescriptionvoidAbstractBase.accept(GraphVisitor<PhysicalOperator> visitor) voidAbstractSubScan.accept(GraphVisitor<PhysicalOperator> visitor) final PhysicalOperatorAbstractReceiver.getNewWithChildren(List<PhysicalOperator> children) final PhysicalOperatorAbstractSingle.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) Constructors in org.apache.drill.exec.physical.base with parameters of type PhysicalOperatorModifierConstructorDescriptionAbstractExchange(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 parameters in org.apache.drill.exec.physical.base with type arguments of type PhysicalOperator -
Uses of PhysicalOperator in org.apache.drill.exec.physical.config
Classes in org.apache.drill.exec.physical.config that implement PhysicalOperatorModifier and TypeClassDescriptionclassDeMuxExchange is opposite of MuxExchange.classMultiplexing 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.classclassclassclassclassclassclassclassclassclassclassclassclassclassclassclassclassclassclassclassclassclassOrderedMuxExchange is a version of MuxExchange where the incoming batches are sorted merge operation is performed to produced a sorted stream as output.classclassclassclassclassclassclassclassclassclassclassclassclassclassSender that pushes all data to a single destination node.classclassclassclassclassclassclassclassclassclassclassUnorderedDeMuxExchange is a version of DeMuxExchange where the incoming batches are not sorted.classUnorderedMuxExchange is a version of MuxExchange where the incoming batches are not sorted.classclassclassclassMethods in org.apache.drill.exec.physical.config that return PhysicalOperatorModifier and TypeMethodDescriptionMetadataControllerPOP.getLeft()RowKeyJoinPOP.getLeft()protected PhysicalOperatorBroadcastExchange.getNewWithChild(PhysicalOperator child) protected PhysicalOperatorBroadcastSender.getNewWithChild(PhysicalOperator child) protected PhysicalOperatorComplexToJson.getNewWithChild(PhysicalOperator child) protected PhysicalOperatorExternalSort.getNewWithChild(PhysicalOperator child) protected PhysicalOperatorFilter.getNewWithChild(PhysicalOperator child) protected PhysicalOperatorFlattenPOP.getNewWithChild(PhysicalOperator child) protected PhysicalOperatorHashAggregate.getNewWithChild(PhysicalOperator child) protected PhysicalOperatorHashPartitionSender.getNewWithChild(PhysicalOperator child) protected PhysicalOperatorHashToMergeExchange.getNewWithChild(PhysicalOperator child) protected PhysicalOperatorHashToRandomExchange.getNewWithChild(PhysicalOperator child) protected PhysicalOperatorIteratorValidator.getNewWithChild(PhysicalOperator child) protected PhysicalOperatorLimit.getNewWithChild(PhysicalOperator child) protected PhysicalOperatorMetadataHandlerPOP.getNewWithChild(PhysicalOperator child) protected PhysicalOperatorMetadataHashAggPOP.getNewWithChild(PhysicalOperator child) protected PhysicalOperatorMetadataStreamAggPOP.getNewWithChild(PhysicalOperator child) protected PhysicalOperatorOrderedMuxExchange.getNewWithChild(PhysicalOperator child) protected PhysicalOperatorOrderedPartitionExchange.getNewWithChild(PhysicalOperator child) protected PhysicalOperatorOrderedPartitionSender.getNewWithChild(PhysicalOperator child) protected PhysicalOperatorPartitionLimit.getNewWithChild(PhysicalOperator child) protected PhysicalOperatorProducerConsumer.getNewWithChild(PhysicalOperator child) protected PhysicalOperatorProject.getNewWithChild(PhysicalOperator child) protected PhysicalOperatorRangePartitionExchange.getNewWithChild(PhysicalOperator child) protected PhysicalOperatorRangePartitionSender.getNewWithChild(PhysicalOperator child) protected PhysicalOperatorRuntimeFilterPOP.getNewWithChild(PhysicalOperator child) protected PhysicalOperatorScreen.getNewWithChild(PhysicalOperator child) protected PhysicalOperatorSelectionVectorRemover.getNewWithChild(PhysicalOperator child) protected PhysicalOperatorSingleMergeExchange.getNewWithChild(PhysicalOperator child) protected PhysicalOperatorSingleSender.getNewWithChild(PhysicalOperator child) protected PhysicalOperatorSort.getNewWithChild(PhysicalOperator child) protected PhysicalOperatorStatisticsAggregate.getNewWithChild(PhysicalOperator child) protected PhysicalOperatorStatisticsMerge.getNewWithChild(PhysicalOperator child) protected PhysicalOperatorStreamingAggregate.getNewWithChild(PhysicalOperator child) protected PhysicalOperatorTableModify.getNewWithChild(PhysicalOperator child) protected PhysicalOperatorTopN.getNewWithChild(PhysicalOperator child) protected PhysicalOperatorTrace.getNewWithChild(PhysicalOperator child) protected PhysicalOperatorUnionExchange.getNewWithChild(PhysicalOperator child) protected PhysicalOperatorUnorderedDeMuxExchange.getNewWithChild(PhysicalOperator child) protected PhysicalOperatorUnorderedMuxExchange.getNewWithChild(PhysicalOperator child) protected PhysicalOperatorUnpivotMaps.getNewWithChild(PhysicalOperator child) protected PhysicalOperatorWindowPOP.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()Methods in org.apache.drill.exec.physical.config that return types with arguments of type PhysicalOperatorModifier and TypeMethodDescriptionFlattenPOP.iterator()MetadataControllerPOP.iterator()RowKeyJoinPOP.iterator()UnnestPOP.iterator()Values.iterator()Methods in org.apache.drill.exec.physical.config with parameters of type PhysicalOperatorModifier and TypeMethodDescriptionprotected PhysicalOperatorBroadcastExchange.getNewWithChild(PhysicalOperator child) protected PhysicalOperatorBroadcastSender.getNewWithChild(PhysicalOperator child) protected PhysicalOperatorComplexToJson.getNewWithChild(PhysicalOperator child) protected PhysicalOperatorExternalSort.getNewWithChild(PhysicalOperator child) protected PhysicalOperatorFilter.getNewWithChild(PhysicalOperator child) protected PhysicalOperatorFlattenPOP.getNewWithChild(PhysicalOperator child) protected PhysicalOperatorHashAggregate.getNewWithChild(PhysicalOperator child) protected PhysicalOperatorHashPartitionSender.getNewWithChild(PhysicalOperator child) protected PhysicalOperatorHashToMergeExchange.getNewWithChild(PhysicalOperator child) protected PhysicalOperatorHashToRandomExchange.getNewWithChild(PhysicalOperator child) protected PhysicalOperatorIteratorValidator.getNewWithChild(PhysicalOperator child) protected PhysicalOperatorLimit.getNewWithChild(PhysicalOperator child) protected PhysicalOperatorMetadataHandlerPOP.getNewWithChild(PhysicalOperator child) protected PhysicalOperatorMetadataHashAggPOP.getNewWithChild(PhysicalOperator child) protected PhysicalOperatorMetadataStreamAggPOP.getNewWithChild(PhysicalOperator child) protected PhysicalOperatorOrderedMuxExchange.getNewWithChild(PhysicalOperator child) protected PhysicalOperatorOrderedPartitionExchange.getNewWithChild(PhysicalOperator child) protected PhysicalOperatorOrderedPartitionSender.getNewWithChild(PhysicalOperator child) protected PhysicalOperatorPartitionLimit.getNewWithChild(PhysicalOperator child) protected PhysicalOperatorProducerConsumer.getNewWithChild(PhysicalOperator child) protected PhysicalOperatorProject.getNewWithChild(PhysicalOperator child) protected PhysicalOperatorRangePartitionExchange.getNewWithChild(PhysicalOperator child) protected PhysicalOperatorRangePartitionSender.getNewWithChild(PhysicalOperator child) protected PhysicalOperatorRuntimeFilterPOP.getNewWithChild(PhysicalOperator child) protected PhysicalOperatorScreen.getNewWithChild(PhysicalOperator child) protected PhysicalOperatorSelectionVectorRemover.getNewWithChild(PhysicalOperator child) protected PhysicalOperatorSingleMergeExchange.getNewWithChild(PhysicalOperator child) protected PhysicalOperatorSingleSender.getNewWithChild(PhysicalOperator child) protected PhysicalOperatorSort.getNewWithChild(PhysicalOperator child) protected PhysicalOperatorStatisticsAggregate.getNewWithChild(PhysicalOperator child) protected PhysicalOperatorStatisticsMerge.getNewWithChild(PhysicalOperator child) protected PhysicalOperatorStreamingAggregate.getNewWithChild(PhysicalOperator child) protected PhysicalOperatorTableModify.getNewWithChild(PhysicalOperator child) protected PhysicalOperatorTopN.getNewWithChild(PhysicalOperator child) protected PhysicalOperatorTrace.getNewWithChild(PhysicalOperator child) protected PhysicalOperatorUnionExchange.getNewWithChild(PhysicalOperator child) protected PhysicalOperatorUnorderedDeMuxExchange.getNewWithChild(PhysicalOperator child) protected PhysicalOperatorUnorderedMuxExchange.getNewWithChild(PhysicalOperator child) protected PhysicalOperatorUnpivotMaps.getNewWithChild(PhysicalOperator child) protected PhysicalOperatorWindowPOP.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) Method parameters in org.apache.drill.exec.physical.config with type arguments of type PhysicalOperatorModifier 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) Constructors in org.apache.drill.exec.physical.config with parameters of type PhysicalOperatorModifierConstructorDescriptionAbstractDeMuxExchange(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) Constructor parameters in org.apache.drill.exec.physical.config with type arguments of type PhysicalOperatorModifierConstructorDescriptionSetOp(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
Classes in org.apache.drill.exec.physical.impl with type parameters of type PhysicalOperatorModifier and TypeInterfaceDescriptioninterfaceBatchCreator<T extends PhysicalOperator>interfaceRootCreator<T extends PhysicalOperator>Methods in org.apache.drill.exec.physical.impl that return PhysicalOperatorModifier and TypeMethodDescriptionstatic PhysicalOperatorTraceInjector.getExec(FragmentContext context, FragmentRoot root) TraceInjector.visitOp(PhysicalOperator op, FragmentContext context) Traverse the physical plan and inject the trace operator after every operator.Methods in org.apache.drill.exec.physical.impl with parameters of type PhysicalOperatorModifier 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.Constructors in org.apache.drill.exec.physical.impl with parameters of type PhysicalOperatorModifierConstructorDescriptionBaseRootExec(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
Classes in org.apache.drill.exec.physical.impl.join with type parameters of type PhysicalOperatorModifier and TypeClassDescriptionclassAbstractHashBinaryRecordBatch<T extends PhysicalOperator>Base class for the runtime execution implementation of the Hash-Join and Hash-SetOp operatorclassProbeTemplate<T extends PhysicalOperator> -
Uses of PhysicalOperator in org.apache.drill.exec.physical.impl.protocol
Constructors in org.apache.drill.exec.physical.impl.protocol with parameters of type PhysicalOperatorModifierConstructorDescriptionOperatorRecordBatch(FragmentContext context, PhysicalOperator config, OperatorExec opExec, boolean enableSchemaBatch) -
Uses of PhysicalOperator in org.apache.drill.exec.physical.impl.scan.project
Methods in org.apache.drill.exec.physical.impl.scan.project with parameters of type PhysicalOperatorModifier and TypeMethodDescriptionScanSchemaOrchestrator.ScanOrchestratorBuilder.buildScanOperator(FragmentContext fragContext, PhysicalOperator pop) -
Uses of PhysicalOperator in org.apache.drill.exec.physical.impl.scan.v3
Methods in org.apache.drill.exec.physical.impl.scan.v3 with parameters of type PhysicalOperatorModifier and TypeMethodDescriptionScanLifecycleBuilder.buildScanOperator(FragmentContext fragContext, PhysicalOperator pop) -
Uses of PhysicalOperator in org.apache.drill.exec.physical.impl.spill
Constructors in org.apache.drill.exec.physical.impl.spill with parameters of type PhysicalOperatorModifierConstructorDescriptionSpillSet(DrillConfig config, ExecProtos.FragmentHandle handle, PhysicalOperator popConfig) SpillSet(FragmentContext context, PhysicalOperator popConfig) -
Uses of PhysicalOperator in org.apache.drill.exec.physical.impl.validate
Methods in org.apache.drill.exec.physical.impl.validate that return PhysicalOperatorModifier and TypeMethodDescriptionIteratorValidatorInjector.visitOp(PhysicalOperator op, FragmentContext context) Traverse the physical plan and inject the IteratorValidator operator after every operator.Methods in org.apache.drill.exec.physical.impl.validate with parameters of type PhysicalOperatorModifier 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
Methods in org.apache.drill.exec.planner with parameters of type PhysicalOperator -
Uses of PhysicalOperator in org.apache.drill.exec.planner.fragment
Methods in org.apache.drill.exec.planner.fragment that return PhysicalOperatorModifier 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) Methods in org.apache.drill.exec.planner.fragment that return types with arguments of type PhysicalOperatorModifier 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()Methods in org.apache.drill.exec.planner.fragment with parameters of type PhysicalOperatorModifier and TypeMethodDescriptionvoidMaterializer.IndexedFragmentNode.addAllocation(PhysicalOperator pop) voidFragment.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) Method parameters in org.apache.drill.exec.planner.fragment with type arguments of type PhysicalOperatorModifier and TypeMethodDescriptionFragment.BufferedOpFinder.visitOp(PhysicalOperator op, List<PhysicalOperator> value) -
Uses of PhysicalOperator in org.apache.drill.exec.planner.fragment.contrib
Methods in org.apache.drill.exec.planner.fragment.contrib that return PhysicalOperatorModifier 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) Methods in org.apache.drill.exec.planner.fragment.contrib with parameters of type PhysicalOperatorModifier and TypeMethodDescriptionExchangeRemoverMaterializer.visitOp(PhysicalOperator op, Materializer.IndexedFragmentNode iNode) OperatorIdVisitor.visitOp(PhysicalOperator op, Integer parentOpId) -
Uses of PhysicalOperator in org.apache.drill.exec.planner.logical
Methods in org.apache.drill.exec.planner.logical with parameters of type PhysicalOperatorModifier and TypeMethodDescriptionCreateTableEntry.getWriter(PhysicalOperator child) FileSystemCreateTableEntry.getWriter(PhysicalOperator child) ModifyTableEntry.getWriter(PhysicalOperator child) -
Uses of PhysicalOperator in org.apache.drill.exec.planner.physical
Methods in org.apache.drill.exec.planner.physical that return PhysicalOperatorModifier 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) Methods in org.apache.drill.exec.planner.physical with parameters of type PhysicalOperatorModifier and TypeMethodDescriptionPhysicalPlanCreator.addMetadata(Prel originalPrel, PhysicalOperator op) -
Uses of PhysicalOperator in org.apache.drill.exec.planner.sql.handlers
Methods in org.apache.drill.exec.planner.sql.handlers that return PhysicalOperatorModifier and TypeMethodDescriptionprotected PhysicalOperatorDefaultSqlHandler.convertToPop(Prel prel) Methods in org.apache.drill.exec.planner.sql.handlers that return types with arguments of type PhysicalOperatorModifier and TypeMethodDescriptionstatic List<PhysicalOperator> DefaultSqlHandler.getPops(PhysicalOperator root) Methods in org.apache.drill.exec.planner.sql.handlers with parameters of type PhysicalOperatorModifier and TypeMethodDescriptionprotected PhysicalPlanDefaultSqlHandler.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
Classes in org.apache.drill.exec.record with type parameters of type PhysicalOperatorModifier and TypeClassDescriptionclassAbstractBinaryRecordBatch<T extends PhysicalOperator>classAbstractRecordBatch<T extends PhysicalOperator>classAbstractSingleRecordBatch<T extends PhysicalOperator>Implements an AbstractUnaryRecordBatch where the incoming record batch is known at the time of creationclassAbstractTableFunctionRecordBatch<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.classAbstractUnaryRecordBatch<T extends PhysicalOperator>Base class for operators that have a single input.Fields in org.apache.drill.exec.record declared as PhysicalOperator -
Uses of PhysicalOperator in org.apache.drill.exec.store.delta
Classes in org.apache.drill.exec.store.delta that implement PhysicalOperatorMethods in org.apache.drill.exec.store.delta that return PhysicalOperatorModifier and TypeMethodDescriptionDeltaGroupScan.getNewWithChildren(List<PhysicalOperator> children) DeltaRowGroupScan.getNewWithChildren(List<PhysicalOperator> children) Method parameters in org.apache.drill.exec.store.delta with type arguments of type PhysicalOperatorModifier and TypeMethodDescriptionDeltaGroupScan.getNewWithChildren(List<PhysicalOperator> children) DeltaRowGroupScan.getNewWithChildren(List<PhysicalOperator> children) -
Uses of PhysicalOperator in org.apache.drill.exec.store.delta.format
Methods in org.apache.drill.exec.store.delta.format with parameters of type PhysicalOperatorModifier and TypeMethodDescriptionDeltaFormatPlugin.getWriter(PhysicalOperator child, String location, List<String> partitionColumns) -
Uses of PhysicalOperator in org.apache.drill.exec.store.dfs
Methods in org.apache.drill.exec.store.dfs with parameters of type PhysicalOperatorModifier and TypeMethodDescriptionFormatPlugin.getWriter(PhysicalOperator child, String location, List<String> partitionColumns) -
Uses of PhysicalOperator in org.apache.drill.exec.store.dfs.easy
Classes in org.apache.drill.exec.store.dfs.easy that implement PhysicalOperatorMethods in org.apache.drill.exec.store.dfs.easy that return PhysicalOperatorModifier and TypeMethodDescriptionprotected PhysicalOperatorEasyWriter.getNewWithChild(PhysicalOperator child) EasyGroupScan.getNewWithChildren(List<PhysicalOperator> children) Methods in org.apache.drill.exec.store.dfs.easy with parameters of type PhysicalOperatorModifier and TypeMethodDescriptionprotected PhysicalOperatorEasyWriter.getNewWithChild(PhysicalOperator child) EasyFormatPlugin.getWriter(PhysicalOperator child, String location, List<String> partitionColumns) Method parameters in org.apache.drill.exec.store.dfs.easy with type arguments of type PhysicalOperatorModifier and TypeMethodDescriptionEasyGroupScan.getNewWithChildren(List<PhysicalOperator> children) Constructors in org.apache.drill.exec.store.dfs.easy with parameters of type PhysicalOperatorModifierConstructorDescriptionEasyWriter(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
Classes in org.apache.drill.exec.store.direct that implement PhysicalOperatorModifier and TypeClassDescriptionclassclassclassRepresents direct scan based on metadata information.Methods in org.apache.drill.exec.store.direct that return PhysicalOperatorModifier and TypeMethodDescriptionDirectGroupScan.getNewWithChildren(List<PhysicalOperator> children) MetadataDirectGroupScan.getNewWithChildren(List<PhysicalOperator> children) Method parameters in org.apache.drill.exec.store.direct with type arguments of type PhysicalOperatorModifier and TypeMethodDescriptionDirectGroupScan.getNewWithChildren(List<PhysicalOperator> children) MetadataDirectGroupScan.getNewWithChildren(List<PhysicalOperator> children) -
Uses of PhysicalOperator in org.apache.drill.exec.store.drill.plugin
Classes in org.apache.drill.exec.store.drill.plugin that implement PhysicalOperatorMethods in org.apache.drill.exec.store.drill.plugin that return PhysicalOperatorModifier and TypeMethodDescriptionDrillGroupScan.getNewWithChildren(List<PhysicalOperator> children) DrillSubScan.getNewWithChildren(List<PhysicalOperator> children) Methods in org.apache.drill.exec.store.drill.plugin that return types with arguments of type PhysicalOperatorMethod parameters in org.apache.drill.exec.store.drill.plugin with type arguments of type PhysicalOperatorModifier and TypeMethodDescriptionDrillGroupScan.getNewWithChildren(List<PhysicalOperator> children) DrillSubScan.getNewWithChildren(List<PhysicalOperator> children) -
Uses of PhysicalOperator in org.apache.drill.exec.store.druid
Classes in org.apache.drill.exec.store.druid that implement PhysicalOperatorModifier and TypeClassDescriptionclassclassA Class containing information to read a single druid data source.Methods in org.apache.drill.exec.store.druid that return PhysicalOperatorModifier and TypeMethodDescriptionDruidGroupScan.getNewWithChildren(List<PhysicalOperator> children) DruidSubScan.getNewWithChildren(List<PhysicalOperator> children) Methods in org.apache.drill.exec.store.druid that return types with arguments of type PhysicalOperatorMethod parameters in org.apache.drill.exec.store.druid with type arguments of type PhysicalOperatorModifier and TypeMethodDescriptionDruidGroupScan.getNewWithChildren(List<PhysicalOperator> children) DruidSubScan.getNewWithChildren(List<PhysicalOperator> children) -
Uses of PhysicalOperator in org.apache.drill.exec.store.enumerable
Classes in org.apache.drill.exec.store.enumerable that implement PhysicalOperatorMethods in org.apache.drill.exec.store.enumerable that return PhysicalOperatorModifier and TypeMethodDescriptionEnumerableGroupScan.getNewWithChildren(List<PhysicalOperator> children) Method parameters in org.apache.drill.exec.store.enumerable with type arguments of type PhysicalOperatorModifier and TypeMethodDescriptionEnumerableGroupScan.getNewWithChildren(List<PhysicalOperator> children) -
Uses of PhysicalOperator in org.apache.drill.exec.store.enumerable.plan
Methods in org.apache.drill.exec.store.enumerable.plan that return PhysicalOperatorModifier and TypeMethodDescriptionEnumerableIntermediatePrel.getPhysicalOperator(PhysicalPlanCreator creator) EnumerablePrel.getPhysicalOperator(PhysicalPlanCreator creator) -
Uses of PhysicalOperator in org.apache.drill.exec.store.googlesheets
Classes in org.apache.drill.exec.store.googlesheets that implement PhysicalOperatorModifier and TypeClassDescriptionclassclassclassclassMethods in org.apache.drill.exec.store.googlesheets that return PhysicalOperatorModifier and TypeMethodDescriptionprotected PhysicalOperatorGoogleSheetsInsertWriter.getNewWithChild(PhysicalOperator child) protected PhysicalOperatorGoogleSheetsWriter.getNewWithChild(PhysicalOperator child) GoogleSheetsGroupScan.getNewWithChildren(List<PhysicalOperator> children) Methods in org.apache.drill.exec.store.googlesheets that return types with arguments of type PhysicalOperatorMethods in org.apache.drill.exec.store.googlesheets with parameters of type PhysicalOperatorModifier and TypeMethodDescriptionprotected PhysicalOperatorGoogleSheetsInsertWriter.getNewWithChild(PhysicalOperator child) protected PhysicalOperatorGoogleSheetsWriter.getNewWithChild(PhysicalOperator child) Method parameters in org.apache.drill.exec.store.googlesheets with type arguments of type PhysicalOperatorModifier and TypeMethodDescriptionGoogleSheetsGroupScan.getNewWithChildren(List<PhysicalOperator> children) Constructors in org.apache.drill.exec.store.googlesheets with parameters of type PhysicalOperatorModifierConstructorDescriptionGoogleSheetsInsertWriter(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
Classes in org.apache.drill.exec.store.hbase that implement PhysicalOperatorModifier and TypeClassDescriptionclassclassInformation for reading a single HBase regionMethods in org.apache.drill.exec.store.hbase that return PhysicalOperatorModifier and TypeMethodDescriptionHBaseGroupScan.getNewWithChildren(List<PhysicalOperator> children) HBaseSubScan.getNewWithChildren(List<PhysicalOperator> children) Methods in org.apache.drill.exec.store.hbase that return types with arguments of type PhysicalOperatorMethod parameters in org.apache.drill.exec.store.hbase with type arguments of type PhysicalOperatorModifier and TypeMethodDescriptionHBaseGroupScan.getNewWithChildren(List<PhysicalOperator> children) HBaseSubScan.getNewWithChildren(List<PhysicalOperator> children) -
Uses of PhysicalOperator in org.apache.drill.exec.store.hive
Classes in org.apache.drill.exec.store.hive that implement PhysicalOperatorModifier and TypeClassDescriptionclassclassclassclassMethods in org.apache.drill.exec.store.hive that return PhysicalOperatorModifier and TypeMethodDescriptionHiveDrillNativeParquetRowGroupScan.getNewWithChildren(List<PhysicalOperator> children) HiveDrillNativeParquetScan.getNewWithChildren(List<PhysicalOperator> children) HiveScan.getNewWithChildren(List<PhysicalOperator> children) HiveSubScan.getNewWithChildren(List<PhysicalOperator> children) Methods in org.apache.drill.exec.store.hive that return types with arguments of type PhysicalOperatorMethod parameters in org.apache.drill.exec.store.hive with type arguments of type PhysicalOperatorModifier 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
Classes in org.apache.drill.exec.store.http that implement PhysicalOperatorMethods in org.apache.drill.exec.store.http that return PhysicalOperatorModifier and TypeMethodDescriptionHttpGroupScan.getNewWithChildren(List<PhysicalOperator> children) HttpSubScan.getNewWithChildren(List<PhysicalOperator> children) Methods in org.apache.drill.exec.store.http that return types with arguments of type PhysicalOperatorMethod parameters in org.apache.drill.exec.store.http with type arguments of type PhysicalOperatorModifier and TypeMethodDescriptionHttpGroupScan.getNewWithChildren(List<PhysicalOperator> children) HttpSubScan.getNewWithChildren(List<PhysicalOperator> children) -
Uses of PhysicalOperator in org.apache.drill.exec.store.iceberg
Classes in org.apache.drill.exec.store.iceberg that implement PhysicalOperatorMethods in org.apache.drill.exec.store.iceberg that return PhysicalOperatorModifier and TypeMethodDescriptionIcebergGroupScan.getNewWithChildren(List<PhysicalOperator> children) IcebergSubScan.getNewWithChildren(List<PhysicalOperator> children) Methods in org.apache.drill.exec.store.iceberg that return types with arguments of type PhysicalOperatorMethod parameters in org.apache.drill.exec.store.iceberg with type arguments of type PhysicalOperatorModifier and TypeMethodDescriptionIcebergGroupScan.getNewWithChildren(List<PhysicalOperator> children) IcebergSubScan.getNewWithChildren(List<PhysicalOperator> children) -
Uses of PhysicalOperator in org.apache.drill.exec.store.iceberg.format
Methods in org.apache.drill.exec.store.iceberg.format with parameters of type PhysicalOperatorModifier and TypeMethodDescriptionIcebergFormatPlugin.getWriter(PhysicalOperator child, String location, List<String> partitionColumns) -
Uses of PhysicalOperator in org.apache.drill.exec.store.ischema
Classes in org.apache.drill.exec.store.ischema that implement PhysicalOperatorMethods in org.apache.drill.exec.store.ischema that return PhysicalOperatorModifier and TypeMethodDescriptionInfoSchemaGroupScan.getNewWithChildren(List<PhysicalOperator> children) Method parameters in org.apache.drill.exec.store.ischema with type arguments of type PhysicalOperatorModifier and TypeMethodDescriptionInfoSchemaGroupScan.getNewWithChildren(List<PhysicalOperator> children) -
Uses of PhysicalOperator in org.apache.drill.exec.store.jdbc
Classes in org.apache.drill.exec.store.jdbc that implement PhysicalOperatorModifier and TypeClassDescriptionclassclassclassclassMethods in org.apache.drill.exec.store.jdbc that return PhysicalOperatorModifier and TypeMethodDescriptionprotected PhysicalOperatorJdbcInsertWriter.getNewWithChild(PhysicalOperator child) protected PhysicalOperatorJdbcWriter.getNewWithChild(PhysicalOperator child) JdbcGroupScan.getNewWithChildren(List<PhysicalOperator> children) JdbcIntermediatePrel.getPhysicalOperator(PhysicalPlanCreator creator) JdbcPrel.getPhysicalOperator(PhysicalPlanCreator creator) Methods in org.apache.drill.exec.store.jdbc with parameters of type PhysicalOperatorModifier and TypeMethodDescriptionprotected PhysicalOperatorJdbcInsertWriter.getNewWithChild(PhysicalOperator child) protected PhysicalOperatorJdbcWriter.getNewWithChild(PhysicalOperator child) Method parameters in org.apache.drill.exec.store.jdbc with type arguments of type PhysicalOperatorModifier and TypeMethodDescriptionJdbcGroupScan.getNewWithChildren(List<PhysicalOperator> children) Constructors in org.apache.drill.exec.store.jdbc with parameters of type PhysicalOperatorModifierConstructorDescriptionJdbcInsertWriter(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
Classes in org.apache.drill.exec.store.kafka that implement PhysicalOperatorMethods in org.apache.drill.exec.store.kafka that return PhysicalOperatorModifier and TypeMethodDescriptionKafkaGroupScan.getNewWithChildren(List<PhysicalOperator> children) KafkaSubScan.getNewWithChildren(List<PhysicalOperator> children) Methods in org.apache.drill.exec.store.kafka that return types with arguments of type PhysicalOperatorMethod parameters in org.apache.drill.exec.store.kafka with type arguments of type PhysicalOperatorModifier and TypeMethodDescriptionKafkaGroupScan.getNewWithChildren(List<PhysicalOperator> children) KafkaSubScan.getNewWithChildren(List<PhysicalOperator> children) -
Uses of PhysicalOperator in org.apache.drill.exec.store.kudu
Classes in org.apache.drill.exec.store.kudu that implement PhysicalOperatorModifier and TypeClassDescriptionclassclassInformation for reading a single Kudu tabletclassMethods in org.apache.drill.exec.store.kudu that return PhysicalOperatorModifier and TypeMethodDescriptionprotected PhysicalOperatorKuduWriter.getNewWithChild(PhysicalOperator child) KuduGroupScan.getNewWithChildren(List<PhysicalOperator> children) KuduSubScan.getNewWithChildren(List<PhysicalOperator> children) Methods in org.apache.drill.exec.store.kudu that return types with arguments of type PhysicalOperatorMethods in org.apache.drill.exec.store.kudu with parameters of type PhysicalOperatorModifier and TypeMethodDescriptionprotected PhysicalOperatorKuduWriter.getNewWithChild(PhysicalOperator child) Method parameters in org.apache.drill.exec.store.kudu with type arguments of type PhysicalOperatorModifier and TypeMethodDescriptionKuduGroupScan.getNewWithChildren(List<PhysicalOperator> children) KuduSubScan.getNewWithChildren(List<PhysicalOperator> children) Constructors in org.apache.drill.exec.store.kudu with parameters of type PhysicalOperatorModifierConstructorDescriptionKuduWriter(PhysicalOperator child, String name, StoragePluginConfig storageConfig, StoragePluginRegistry engineRegistry) -
Uses of PhysicalOperator in org.apache.drill.exec.store.mock
Classes in org.apache.drill.exec.store.mock that implement PhysicalOperatorModifier and TypeClassDescriptionclassDescribes a "group" scan of a (logical) mock table.classclassDescribes a physical scan operation for the mock data source.Methods in org.apache.drill.exec.store.mock that return PhysicalOperatorModifier and TypeMethodDescriptionprotected PhysicalOperatorMockStorePOP.getNewWithChild(PhysicalOperator child) MockGroupScanPOP.getNewWithChildren(List<PhysicalOperator> children) MockSubScanPOP.getNewWithChildren(List<PhysicalOperator> children) Methods in org.apache.drill.exec.store.mock that return types with arguments of type PhysicalOperatorMethods in org.apache.drill.exec.store.mock with parameters of type PhysicalOperatorModifier and TypeMethodDescriptionprotected PhysicalOperatorMockStorePOP.getNewWithChild(PhysicalOperator child) MockStorePOP.getSpecificStore(PhysicalOperator child, int minorFragmentId) Method parameters in org.apache.drill.exec.store.mock with type arguments of type PhysicalOperatorModifier and TypeMethodDescriptionMockGroupScanPOP.getNewWithChildren(List<PhysicalOperator> children) MockSubScanPOP.getNewWithChildren(List<PhysicalOperator> children) Constructors in org.apache.drill.exec.store.mock with parameters of type PhysicalOperator -
Uses of PhysicalOperator in org.apache.drill.exec.store.mongo
Classes in org.apache.drill.exec.store.mongo that implement PhysicalOperatorMethods in org.apache.drill.exec.store.mongo that return PhysicalOperatorModifier and TypeMethodDescriptionMongoGroupScan.getNewWithChildren(List<PhysicalOperator> children) MongoSubScan.getNewWithChildren(List<PhysicalOperator> children) Methods in org.apache.drill.exec.store.mongo that return types with arguments of type PhysicalOperatorMethod parameters in org.apache.drill.exec.store.mongo with type arguments of type PhysicalOperatorModifier and TypeMethodDescriptionMongoGroupScan.getNewWithChildren(List<PhysicalOperator> children) MongoSubScan.getNewWithChildren(List<PhysicalOperator> children) -
Uses of PhysicalOperator in org.apache.drill.exec.store.openTSDB
Classes in org.apache.drill.exec.store.openTSDB that implement PhysicalOperatorMethods in org.apache.drill.exec.store.openTSDB that return PhysicalOperatorModifier and TypeMethodDescriptionOpenTSDBGroupScan.getNewWithChildren(List<PhysicalOperator> children) OpenTSDBSubScan.getNewWithChildren(List<PhysicalOperator> children) Methods in org.apache.drill.exec.store.openTSDB that return types with arguments of type PhysicalOperatorMethod parameters in org.apache.drill.exec.store.openTSDB with type arguments of type PhysicalOperatorModifier and TypeMethodDescriptionOpenTSDBGroupScan.getNewWithChildren(List<PhysicalOperator> children) OpenTSDBSubScan.getNewWithChildren(List<PhysicalOperator> children) -
Uses of PhysicalOperator in org.apache.drill.exec.store.parquet
Classes in org.apache.drill.exec.store.parquet that implement PhysicalOperatorModifier and TypeClassDescriptionclassclassclassclassclassMethods in org.apache.drill.exec.store.parquet that return PhysicalOperatorModifier and TypeMethodDescriptionprotected PhysicalOperatorParquetWriter.getNewWithChild(PhysicalOperator child) ParquetGroupScan.getNewWithChildren(List<PhysicalOperator> children) ParquetRowGroupScan.getNewWithChildren(List<PhysicalOperator> children) Methods in org.apache.drill.exec.store.parquet that return types with arguments of type PhysicalOperatorMethods in org.apache.drill.exec.store.parquet with parameters of type PhysicalOperatorModifier and TypeMethodDescriptionprotected PhysicalOperatorParquetWriter.getNewWithChild(PhysicalOperator child) ParquetFormatPlugin.getWriter(PhysicalOperator child, String location, List<String> partitionColumns) Method parameters in org.apache.drill.exec.store.parquet with type arguments of type PhysicalOperatorModifier and TypeMethodDescriptionParquetGroupScan.getNewWithChildren(List<PhysicalOperator> children) ParquetRowGroupScan.getNewWithChildren(List<PhysicalOperator> children) Constructors in org.apache.drill.exec.store.parquet with parameters of type PhysicalOperatorModifierConstructorDescriptionParquetWriter(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
Classes in org.apache.drill.exec.store.phoenix that implement PhysicalOperatorMethods in org.apache.drill.exec.store.phoenix that return PhysicalOperatorModifier and TypeMethodDescriptionPhoenixGroupScan.getNewWithChildren(List<PhysicalOperator> children) PhoenixSubScan.getNewWithChildren(List<PhysicalOperator> children) Methods in org.apache.drill.exec.store.phoenix that return types with arguments of type PhysicalOperatorMethod parameters in org.apache.drill.exec.store.phoenix with type arguments of type PhysicalOperatorModifier and TypeMethodDescriptionPhoenixGroupScan.getNewWithChildren(List<PhysicalOperator> children) PhoenixSubScan.getNewWithChildren(List<PhysicalOperator> children) -
Uses of PhysicalOperator in org.apache.drill.exec.store.phoenix.rules
Methods in org.apache.drill.exec.store.phoenix.rules that return PhysicalOperatorModifier and TypeMethodDescriptionPhoenixIntermediatePrel.getPhysicalOperator(PhysicalPlanCreator creator) PhoenixPrel.getPhysicalOperator(PhysicalPlanCreator creator) -
Uses of PhysicalOperator in org.apache.drill.exec.store.plan.rel
Methods in org.apache.drill.exec.store.plan.rel that return PhysicalOperatorModifier and TypeMethodDescriptionPluginIntermediatePrel.getPhysicalOperator(PhysicalPlanCreator creator) PluginPrel.getPhysicalOperator(PhysicalPlanCreator creator) -
Uses of PhysicalOperator in org.apache.drill.exec.store.splunk
Classes in org.apache.drill.exec.store.splunk that implement PhysicalOperatorModifier and TypeClassDescriptionclassclassclassclassMethods in org.apache.drill.exec.store.splunk that return PhysicalOperatorModifier and TypeMethodDescriptionprotected PhysicalOperatorSplunkInsertWriter.getNewWithChild(PhysicalOperator child) protected PhysicalOperatorSplunkWriter.getNewWithChild(PhysicalOperator child) SplunkGroupScan.getNewWithChildren(List<PhysicalOperator> children) SplunkSubScan.getNewWithChildren(List<PhysicalOperator> children) Methods in org.apache.drill.exec.store.splunk that return types with arguments of type PhysicalOperatorMethods in org.apache.drill.exec.store.splunk with parameters of type PhysicalOperatorModifier and TypeMethodDescriptionprotected PhysicalOperatorSplunkInsertWriter.getNewWithChild(PhysicalOperator child) protected PhysicalOperatorSplunkWriter.getNewWithChild(PhysicalOperator child) Method parameters in org.apache.drill.exec.store.splunk with type arguments of type PhysicalOperatorModifier and TypeMethodDescriptionSplunkGroupScan.getNewWithChildren(List<PhysicalOperator> children) SplunkSubScan.getNewWithChildren(List<PhysicalOperator> children) Constructors in org.apache.drill.exec.store.splunk with parameters of type PhysicalOperatorModifierConstructorDescriptionSplunkInsertWriter(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
Classes in org.apache.drill.exec.store.sys that implement PhysicalOperatorMethods in org.apache.drill.exec.store.sys that return PhysicalOperatorModifier and TypeMethodDescriptionSystemTableScan.getNewWithChildren(List<PhysicalOperator> children) Method parameters in org.apache.drill.exec.store.sys with type arguments of type PhysicalOperatorModifier and TypeMethodDescriptionSystemTableScan.getNewWithChildren(List<PhysicalOperator> children) -
Uses of PhysicalOperator in org.apache.drill.exec.util
Methods in org.apache.drill.exec.util that return types with arguments of type PhysicalOperatorModifier and TypeMethodDescriptionstatic List<PhysicalOperator> MemoryAllocationUtilities.getBufferedOperators(List<PhysicalOperator> operators, QueryContext queryContext) Method parameters in org.apache.drill.exec.util with type arguments of type PhysicalOperatorModifier and TypeMethodDescriptionstatic List<PhysicalOperator> MemoryAllocationUtilities.getBufferedOperators(List<PhysicalOperator> operators, QueryContext queryContext) static voidMemoryAllocationUtilities.setupBufferedOpsMemoryAllocations(boolean planHasMemory, List<PhysicalOperator> bufferedOperators, QueryContext queryContext) Helper method to setup Memory Allocations -
Uses of PhysicalOperator in org.apache.drill.exec.work.filter
Methods in org.apache.drill.exec.work.filter with parameters of type PhysicalOperatorModifier 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
Methods in org.apache.drill.exec.work.foreman.rm with parameters of type PhysicalOperatorModifier and TypeMethodDescriptionThrottledResourceManager.QueuedResourceAllocator.BufferedOpFinder.visitOp(PhysicalOperator op, List<PhysicalOperator> value) Method parameters in org.apache.drill.exec.work.foreman.rm with type arguments of type PhysicalOperatorModifier and TypeMethodDescriptionThrottledResourceManager.QueuedResourceAllocator.BufferedOpFinder.visitOp(PhysicalOperator op, List<PhysicalOperator> value)