public class BeamSideInputJoinRel extends BeamJoinRel
BeamJoinRel
which does sideinput Join
This Join Covers the case:
sideInput
is utilized to implement the join, so there are some constraints:
FULL OUTER JOIN
is not supported.
LEFT OUTER JOIN
, the unbounded table should on the left side.
RIGHT OUTER JOIN
, the unbounded table should on the right side.
General constraints:
condition, hints, joinInfo, joinType, variablesSet
Constructor and Description |
---|
BeamSideInputJoinRel(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) |
PCollection<Row> |
sideInputJoin(PCollection<Row> leftRows,
PCollection<Row> rightRows,
FieldAccessDescriptor leftKeyFields,
FieldAccessDescriptor rightKeyFields) |
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 BeamSideInputJoinRel(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 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
public PTransform<PCollectionList<Row>,PCollection<Row>> buildPTransform()
public PCollection<Row> sideInputJoin(PCollection<Row> leftRows, PCollection<Row> rightRows, FieldAccessDescriptor leftKeyFields, FieldAccessDescriptor rightKeyFields)