public class BeamUnnestRel extends org.apache.calcite.rel.core.Correlate implements BeamRelNode
Constructor and Description |
---|
BeamUnnestRel(org.apache.calcite.plan.RelOptCluster cluster,
org.apache.calcite.plan.RelTraitSet traits,
org.apache.calcite.rel.RelNode left,
org.apache.calcite.rel.RelNode right,
org.apache.calcite.rel.core.CorrelationId correlationId,
org.apache.calcite.util.ImmutableBitSet requiredColumns,
org.apache.calcite.sql.SemiJoinType joinType) |
Modifier and Type | Method and Description |
---|---|
org.apache.calcite.rel.core.Correlate |
copy(org.apache.calcite.plan.RelTraitSet relTraitSet,
org.apache.calcite.rel.RelNode left,
org.apache.calcite.rel.RelNode right,
org.apache.calcite.rel.core.CorrelationId correlationId,
org.apache.calcite.util.ImmutableBitSet requireColumns,
org.apache.calcite.sql.SemiJoinType joinType) |
PTransform<PCollectionTuple,PCollection<Row>> |
toPTransform()
A
BeamRelNode is a recursive structure, the BeamQueryPlanner visits it with a
DFS(Depth-First-Search) algorithm. |
computeSelfCost, copy, deriveRowType, explainTerms, getCorrelationId, getCorrelVariable, getJoinType, getRequiredColumns, getVariablesSet, isValid
childrenAccept, getInputs, getLeft, getRight, replaceInput
accept, accept, collectVariablesSet, collectVariablesUsed, computeDigest, computeSelfCost, estimateRowCount, explain, getChildExps, getCluster, getCollationList, getConvention, getDescription, getDigest, getExpectedInputRowType, getId, getInput, getQuery, getRelTypeName, getRows, getRowType, getTable, getTraitSet, getVariablesStopped, isDistinct, isKey, isValid, metadata, onRegister, recomputeDigest, register, sole, toString
clone, equals, finalize, getClass, hashCode, notify, notifyAll, wait, wait, wait
accept, accept, childrenAccept, collectVariablesSet, collectVariablesUsed, computeSelfCost, computeSelfCost, copy, estimateRowCount, explain, getChildExps, getCollationList, getConvention, getCorrelVariable, getExpectedInputRowType, getInput, getInputs, getQuery, getRelTypeName, getRows, getRowType, getTable, getVariablesSet, getVariablesStopped, isDistinct, isKey, isValid, isValid, metadata, onRegister, recomputeDigest, register, replaceInput
public BeamUnnestRel(org.apache.calcite.plan.RelOptCluster cluster, org.apache.calcite.plan.RelTraitSet traits, org.apache.calcite.rel.RelNode left, org.apache.calcite.rel.RelNode right, org.apache.calcite.rel.core.CorrelationId correlationId, org.apache.calcite.util.ImmutableBitSet requiredColumns, org.apache.calcite.sql.SemiJoinType joinType)
public PTransform<PCollectionTuple,PCollection<Row>> toPTransform()
BeamRelNode
BeamRelNode
is a recursive structure, the BeamQueryPlanner
visits it with a
DFS(Depth-First-Search) algorithm.toPTransform
in interface BeamRelNode
public org.apache.calcite.rel.core.Correlate copy(org.apache.calcite.plan.RelTraitSet relTraitSet, org.apache.calcite.rel.RelNode left, org.apache.calcite.rel.RelNode right, org.apache.calcite.rel.core.CorrelationId correlationId, org.apache.calcite.util.ImmutableBitSet requireColumns, org.apache.calcite.sql.SemiJoinType joinType)
copy
in class org.apache.calcite.rel.core.Correlate