Class BeamJoinRel
java.lang.Object
org.apache.beam.vendor.calcite.v1_40_0.org.apache.calcite.rel.AbstractRelNode
org.apache.beam.vendor.calcite.v1_40_0.org.apache.calcite.rel.BiRel
org.apache.beam.vendor.calcite.v1_40_0.org.apache.calcite.rel.core.Join
org.apache.beam.sdk.extensions.sql.impl.rel.BeamJoinRel
- All Implemented Interfaces:
- Cloneable,- BeamRelNode,- org.apache.beam.vendor.calcite.v1_40_0.org.apache.calcite.plan.RelOptNode,- org.apache.beam.vendor.calcite.v1_40_0.org.apache.calcite.rel.hint.Hintable,- org.apache.beam.vendor.calcite.v1_40_0.org.apache.calcite.rel.RelNode
- Direct Known Subclasses:
- BeamCoGBKJoinRel,- BeamSideInputJoinRel,- BeamSideInputLookupJoinRel
public abstract class BeamJoinRel
extends org.apache.beam.vendor.calcite.v1_40_0.org.apache.calcite.rel.core.Join
implements BeamRelNode
An abstract 
BeamRelNode to implement Join Rels.
 Support for join can be categorized into 4 cases:
- BoundedTable JOIN BoundedTable
- UnboundedTable JOIN UnboundedTable
- BoundedTable JOIN UnboundedTable
- SeekableTable JOIN non SeekableTable
- 
Nested Class SummaryNested classes/interfaces inherited from interface org.apache.beam.vendor.calcite.v1_40_0.org.apache.calcite.rel.RelNodeorg.apache.beam.vendor.calcite.v1_40_0.org.apache.calcite.rel.RelNode.Context
- 
Field SummaryFields inherited from class org.apache.beam.vendor.calcite.v1_40_0.org.apache.calcite.rel.core.Joincondition, hints, joinInfo, joinType, variablesSetFields inherited from class org.apache.beam.vendor.calcite.v1_40_0.org.apache.calcite.rel.BiRelleft, rightFields inherited from class org.apache.beam.vendor.calcite.v1_40_0.org.apache.calcite.rel.AbstractRelNodedigest, id, rowType, traitSet
- 
Constructor SummaryConstructorsModifierConstructorDescriptionprotectedBeamJoinRel(org.apache.beam.vendor.calcite.v1_40_0.org.apache.calcite.plan.RelOptCluster cluster, org.apache.beam.vendor.calcite.v1_40_0.org.apache.calcite.plan.RelTraitSet traits, org.apache.beam.vendor.calcite.v1_40_0.org.apache.calcite.rel.RelNode left, org.apache.beam.vendor.calcite.v1_40_0.org.apache.calcite.rel.RelNode right, org.apache.beam.vendor.calcite.v1_40_0.org.apache.calcite.rex.RexNode condition, Set<org.apache.beam.vendor.calcite.v1_40_0.org.apache.calcite.rel.core.CorrelationId> variablesSet, org.apache.beam.vendor.calcite.v1_40_0.org.apache.calcite.rel.core.JoinRelType joinType) 
- 
Method SummaryModifier and TypeMethodDescriptionbeamComputeSelfCost(org.apache.beam.vendor.calcite.v1_40_0.org.apache.calcite.plan.RelOptPlanner planner, BeamRelMetadataQuery mq) This method is called byorg.apache.beam.sdk.extensions.sql.impl.CalciteQueryPlanner.NonCumulativeCostImpl.static booleancontainsSeekableInput(org.apache.beam.vendor.calcite.v1_40_0.org.apache.calcite.rel.RelNode relNode) This method returns whether any of the children of the relNode are Seekable.This method is called byorg.apache.beam.sdk.extensions.sql.impl.planner.RelMdNodeStats.static PCollection.IsBoundedgetBoundednessOfRelNode(org.apache.beam.vendor.calcite.v1_40_0.org.apache.calcite.rel.RelNode relNode) This method returns the Boundedness of a RelNode.List<org.apache.beam.vendor.calcite.v1_40_0.org.apache.calcite.rel.RelNode> static booleanisJoinLegal(org.apache.beam.vendor.calcite.v1_40_0.org.apache.calcite.rel.core.Join join) This method checks if a join is legal and can be converted into Beam SQL.protected booleanprotected org.apache.beam.vendor.guava.v32_1_2_jre.com.google.common.base.Optional<Integer> static booleanseekable(BeamRelNode relNode) check ifBeamRelNodeimplementsBeamSeekableTable.protected org.apache.beam.vendor.guava.v32_1_2_jre.com.google.common.base.Optional<Integer> Methods inherited from class org.apache.beam.vendor.calcite.v1_40_0.org.apache.calcite.rel.core.Joinaccept, analyzeCondition, computeSelfCost, copy, copy, createJoinType, deepEquals0, deepHashCode0, deriveJoinRowType, deriveRowType, estimateJoinedRows, estimateRowCount, explainTerms, getCondition, getHints, getJoinType, getSystemFieldList, getVariablesSet, isSemiJoin, isSemiJoinDone, isValidMethods inherited from class org.apache.beam.vendor.calcite.v1_40_0.org.apache.calcite.rel.BiRelchildrenAccept, getInputs, getLeft, getRight, replaceInputMethods inherited from class org.apache.beam.vendor.calcite.v1_40_0.org.apache.calcite.rel.AbstractRelNodeaccept, 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, toStringMethods inherited from class java.lang.Objectclone, finalize, getClass, notify, notifyAll, wait, wait, waitMethods inherited from interface org.apache.beam.sdk.extensions.sql.impl.rel.BeamRelNodebuildPTransform, buildPTransform, getPipelineOptions, isBounded, withErrorsTransformerMethods inherited from interface org.apache.beam.vendor.calcite.v1_40_0.org.apache.calcite.rel.hint.HintableattachHints, withHintsMethods inherited from interface org.apache.beam.vendor.calcite.v1_40_0.org.apache.calcite.rel.RelNodeaccept, 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, strippedMethods inherited from interface org.apache.beam.vendor.calcite.v1_40_0.org.apache.calcite.plan.RelOptNodegetCluster, getDescription, getId, getTraitSet
- 
Constructor Details- 
BeamJoinRelprotected BeamJoinRel(org.apache.beam.vendor.calcite.v1_40_0.org.apache.calcite.plan.RelOptCluster cluster, org.apache.beam.vendor.calcite.v1_40_0.org.apache.calcite.plan.RelTraitSet traits, org.apache.beam.vendor.calcite.v1_40_0.org.apache.calcite.rel.RelNode left, org.apache.beam.vendor.calcite.v1_40_0.org.apache.calcite.rel.RelNode right, org.apache.beam.vendor.calcite.v1_40_0.org.apache.calcite.rex.RexNode condition, Set<org.apache.beam.vendor.calcite.v1_40_0.org.apache.calcite.rel.core.CorrelationId> variablesSet, org.apache.beam.vendor.calcite.v1_40_0.org.apache.calcite.rel.core.JoinRelType joinType) 
 
- 
- 
Method Details- 
getPCollectionInputspublic List<org.apache.beam.vendor.calcite.v1_40_0.org.apache.calcite.rel.RelNode> getPCollectionInputs()- Specified by:
- getPCollectionInputsin interface- BeamRelNode
 
- 
isSideInputLookupJoinprotected boolean isSideInputLookupJoin()
- 
seekableInputIndexprotected org.apache.beam.vendor.guava.v32_1_2_jre.com.google.common.base.Optional<Integer> seekableInputIndex()
- 
nonSeekableInputIndexprotected org.apache.beam.vendor.guava.v32_1_2_jre.com.google.common.base.Optional<Integer> nonSeekableInputIndex()
- 
seekablecheck ifBeamRelNodeimplementsBeamSeekableTable.
- 
beamComputeSelfCostpublic BeamCostModel beamComputeSelfCost(org.apache.beam.vendor.calcite.v1_40_0.org.apache.calcite.plan.RelOptPlanner planner, BeamRelMetadataQuery mq) Description copied from interface:BeamRelNodeThis method is called byorg.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 (seeorg.apache.beam.sdk.extensions.sql.impl.CalciteQueryPlanner#convertToBeamRel(String))- Specified by:
- beamComputeSelfCostin interface- BeamRelNode
 
- 
estimateNodeStatsDescription copied from interface:BeamRelNodeThis method is called byorg.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 callinstead.invalid referenceorg.apache.beam.sdk.extensions.sql.impl.rel.BeamSqlRelUtils#getNodeStats(org.apache.beam.vendor.calcite.v1_40_0.org.apache.calcite.rel.RelNode, org.apache.beam.vendor.calcite.v1_40_0.org.apache.calcite.rel.metadata.RelMetadataQuery)- Specified by:
- estimateNodeStatsin interface- BeamRelNode
 
- 
isJoinLegalpublic static boolean isJoinLegal(org.apache.beam.vendor.calcite.v1_40_0.org.apache.calcite.rel.core.Join join) This method checks if a join is legal and can be converted into Beam SQL. It is used during planning and applyingBeamJoinAssociateRuleandBeamJoinPushThroughJoinRule
- 
getBoundednessOfRelNodepublic static PCollection.IsBounded getBoundednessOfRelNode(org.apache.beam.vendor.calcite.v1_40_0.org.apache.calcite.rel.RelNode relNode) This method returns the Boundedness of a RelNode. It is used during planning and applyingBeamCoGBKJoinRuleandBeamSideInputJoinRuleThe Volcano planner works in a top-down fashion. It starts by transforming the root and move towards the leafs of the plan. Due to this when transforming a logical join its inputs are still in the logical convention. So, Recursively visit the inputs of the RelNode till BeamIOSourceRel is encountered and propagate the boundedness upwards. The Boundedness of each child of a RelNode is stored in a list. If any of the children are Unbounded, the RelNode is Unbounded. Else, the RelNode is Bounded. - Parameters:
- relNode- the RelNode whose Boundedness has to be determined
- Returns:
- PCollection.isBounded
 
- 
containsSeekableInputpublic static boolean containsSeekableInput(org.apache.beam.vendor.calcite.v1_40_0.org.apache.calcite.rel.RelNode relNode) This method returns whether any of the children of the relNode are Seekable. It is used during planning and applyingBeamCoGBKJoinRuleandBeamSideInputJoinRuleandBeamSideInputLookupJoinRule- Parameters:
- relNode- the relNode whose children can be Seekable
- Returns:
- A boolean
 
 
-