public class BeamCoGBKJoinRel extends BeamJoinRel
BeamJoinRel
which does CoGBK Join
This Join Covers the cases:
A CoGBK join is utilized as long as the windowFn of the both sides match. For more info refer BEAM-3345
General constraints:
condition, hints, joinInfo, joinType, variablesSet
Constructor and Description |
---|
BeamCoGBKJoinRel(org.apache.beam.vendor.calcite.v1_28_0.org.apache.calcite.plan.RelOptCluster cluster,
org.apache.beam.vendor.calcite.v1_28_0.org.apache.calcite.plan.RelTraitSet traitSet,
org.apache.beam.vendor.calcite.v1_28_0.org.apache.calcite.rel.RelNode left,
org.apache.beam.vendor.calcite.v1_28_0.org.apache.calcite.rel.RelNode right,
org.apache.beam.vendor.calcite.v1_28_0.org.apache.calcite.rex.RexNode condition,
java.util.Set<org.apache.beam.vendor.calcite.v1_28_0.org.apache.calcite.rel.core.CorrelationId> variablesSet,
org.apache.beam.vendor.calcite.v1_28_0.org.apache.calcite.rel.core.JoinRelType joinType) |
Modifier and Type | Method and Description |
---|---|
PTransform<PCollectionList<Row>,PCollection<Row>> |
buildPTransform() |
org.apache.beam.vendor.calcite.v1_28_0.org.apache.calcite.rel.core.Join |
copy(org.apache.beam.vendor.calcite.v1_28_0.org.apache.calcite.plan.RelTraitSet traitSet,
org.apache.beam.vendor.calcite.v1_28_0.org.apache.calcite.rex.RexNode conditionExpr,
org.apache.beam.vendor.calcite.v1_28_0.org.apache.calcite.rel.RelNode left,
org.apache.beam.vendor.calcite.v1_28_0.org.apache.calcite.rel.RelNode right,
org.apache.beam.vendor.calcite.v1_28_0.org.apache.calcite.rel.core.JoinRelType joinType,
boolean semiJoinDone) |
beamComputeSelfCost, containsSeekableInput, estimateNodeStats, getBoundednessOfRelNode, getPCollectionInputs, isJoinLegal, isSideInputLookupJoin, nonSeekableInputIndex, seekable, seekableInputIndex
accept, analyzeCondition, computeSelfCost, copy, createJoinType, deepEquals0, deepHashCode0, deriveJoinRowType, deriveRowType, estimateJoinedRows, estimateRowCount, explainTerms, getCondition, getHints, getJoinType, getSystemFieldList, getVariablesSet, isSemiJoin, isSemiJoinDone, isValid
childrenAccept, getInputs, getLeft, getRight, replaceInput
accept, collectVariablesSet, collectVariablesUsed, deepEquals, deepHashCode, equals, explain, getCluster, getConvention, getCorrelVariable, getDescription, getDigest, getExpectedInputRowType, getId, getInput, getRelDigest, getRelTypeName, getRowType, getTable, getTraitSet, hashCode, isEnforcer, metadata, onRegister, recomputeDigest, register, sole, toString
clone, finalize, getClass, notify, notifyAll, wait, wait, wait
buildPTransform, getPipelineOptions, isBounded, withErrorsTransformer
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
public BeamCoGBKJoinRel(org.apache.beam.vendor.calcite.v1_28_0.org.apache.calcite.plan.RelOptCluster cluster, org.apache.beam.vendor.calcite.v1_28_0.org.apache.calcite.plan.RelTraitSet traitSet, org.apache.beam.vendor.calcite.v1_28_0.org.apache.calcite.rel.RelNode left, org.apache.beam.vendor.calcite.v1_28_0.org.apache.calcite.rel.RelNode right, org.apache.beam.vendor.calcite.v1_28_0.org.apache.calcite.rex.RexNode condition, java.util.Set<org.apache.beam.vendor.calcite.v1_28_0.org.apache.calcite.rel.core.CorrelationId> variablesSet, org.apache.beam.vendor.calcite.v1_28_0.org.apache.calcite.rel.core.JoinRelType joinType)
public PTransform<PCollectionList<Row>,PCollection<Row>> buildPTransform()
public org.apache.beam.vendor.calcite.v1_28_0.org.apache.calcite.rel.core.Join copy(org.apache.beam.vendor.calcite.v1_28_0.org.apache.calcite.plan.RelTraitSet traitSet, org.apache.beam.vendor.calcite.v1_28_0.org.apache.calcite.rex.RexNode conditionExpr, org.apache.beam.vendor.calcite.v1_28_0.org.apache.calcite.rel.RelNode left, org.apache.beam.vendor.calcite.v1_28_0.org.apache.calcite.rel.RelNode right, org.apache.beam.vendor.calcite.v1_28_0.org.apache.calcite.rel.core.JoinRelType joinType, boolean semiJoinDone)
copy
in class org.apache.beam.vendor.calcite.v1_28_0.org.apache.calcite.rel.core.Join