public interface BeamRelNode
extends org.apache.beam.vendor.calcite.v1_28_0.org.apache.calcite.rel.RelNode
RelNode
that can also give a PTransform
that implements the expression.Modifier and Type | Method and Description |
---|---|
BeamCostModel |
beamComputeSelfCost(org.apache.beam.vendor.calcite.v1_28_0.org.apache.calcite.plan.RelOptPlanner planner,
BeamRelMetadataQuery mq)
This method is called by
org.apache.beam.sdk.extensions.sql.impl.CalciteQueryPlanner.NonCumulativeCostImpl . |
PTransform<PCollectionList<Row>,PCollection<Row>> |
buildPTransform() |
default PTransform<PCollectionList<Row>,PCollection<Row>> |
buildPTransform(@Nullable PTransform<PCollection<Row>,? extends POutput> errorsTransformer) |
NodeStats |
estimateNodeStats(BeamRelMetadataQuery mq)
This method is called by
org.apache.beam.sdk.extensions.sql.impl.planner.RelMdNodeStats . |
default java.util.List<org.apache.beam.vendor.calcite.v1_28_0.org.apache.calcite.rel.RelNode> |
getPCollectionInputs() |
default java.util.Map<java.lang.String,java.lang.String> |
getPipelineOptions()
Perform a DFS(Depth-First-Search) to find the PipelineOptions config.
|
default PCollection.IsBounded |
isBounded()
Whether the collection of rows represented by this relational expression is bounded (known to
be finite) or unbounded (may or may not be finite).
|
default void |
withErrorsTransformer(@Nullable PTransform<PCollection<Row>,POutput> ptransform) |
accept, accept, childrenAccept, collectVariablesSet, collectVariablesUsed, computeSelfCost, copy, deepEquals, deepHashCode, estimateRowCount, explain, explain, fieldIsNullable, getConvention, getCorrelVariable, getDigest, getExpectedInputRowType, getInput, getInputs, getRelDigest, getRelTypeName, getRowType, getTable, getVariablesSet, isEnforcer, isValid, metadata, onRegister, recomputeDigest, register, replaceInput
default PCollection.IsBounded isBounded()
default void withErrorsTransformer(@Nullable PTransform<PCollection<Row>,POutput> ptransform)
default java.util.List<org.apache.beam.vendor.calcite.v1_28_0.org.apache.calcite.rel.RelNode> getPCollectionInputs()
PTransform<PCollectionList<Row>,PCollection<Row>> buildPTransform()
default PTransform<PCollectionList<Row>,PCollection<Row>> buildPTransform(@Nullable PTransform<PCollection<Row>,? extends POutput> errorsTransformer)
default java.util.Map<java.lang.String,java.lang.String> getPipelineOptions()
NodeStats estimateNodeStats(BeamRelMetadataQuery mq)
org.apache.beam.sdk.extensions.sql.impl.planner.RelMdNodeStats
. This is currently only used in
SQLTransform Path (and not JDBC path). When a RelNode wants to calculate its BeamCost or
estimate its NodeStats, it may need NodeStat of its inputs. However, it should not call this
directly (because maybe its inputs are not physical yet). It should call org.apache.beam.sdk.extensions.sql.impl.rel.BeamSqlRelUtils#getNodeStats(
org.apache.beam.vendor.calcite.v1_28_0.org.apache.calcite.rel.RelNode,
org.apache.beam.vendor.calcite.v1_28_0.org.apache.calcite.rel.metadata.RelMetadataQuery)
instead.BeamCostModel beamComputeSelfCost(org.apache.beam.vendor.calcite.v1_28_0.org.apache.calcite.plan.RelOptPlanner planner, BeamRelMetadataQuery mq)
org.apache.beam.sdk.extensions.sql.impl.CalciteQueryPlanner.NonCumulativeCostImpl
. This is
currently only used in SQLTransform Path (and not JDBC path). This is needed when Calcite Query
Planner wants to get the cost of a plan. Instead of calling this directly for a node, if we
needed that it should be obtained by calling mq.getNonCumulativeCost. This way RelMetadataQuery
will call this method instead of ComputeSelfCost if the handler is set correctly (see org.apache.beam.sdk.extensions.sql.impl.CalciteQueryPlanner#convertToBeamRel(String)
)