public class HiveJoin extends org.apache.calcite.rel.core.Join implements HiveRelNode
Modifier and Type | Class and Description |
---|---|
static class |
HiveJoin.MapJoinStreamingRelation |
HiveRelNode.Implementor
Modifier and Type | Field and Description |
---|---|
static org.apache.calcite.rel.core.RelFactories.JoinFactory |
HIVE_JOIN_FACTORY |
CONVENTION
Modifier | Constructor and Description |
---|---|
protected |
HiveJoin(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.rex.RexNode condition,
org.apache.calcite.rel.core.JoinRelType joinType,
Set<String> variablesStopped,
HiveCostModel.JoinAlgorithm joinAlgo,
boolean leftSemiJoin) |
Modifier and Type | Method and Description |
---|---|
org.apache.calcite.plan.RelOptCost |
computeSelfCost(org.apache.calcite.plan.RelOptPlanner planner)
Model cost of join as size of Inputs.
|
HiveJoin |
copy(org.apache.calcite.plan.RelTraitSet traitSet,
org.apache.calcite.rex.RexNode conditionExpr,
org.apache.calcite.rel.RelNode left,
org.apache.calcite.rel.RelNode right,
org.apache.calcite.rel.core.JoinRelType joinType,
boolean semiJoinDone) |
org.apache.calcite.rel.type.RelDataType |
deriveRowType() |
org.apache.calcite.rel.RelWriter |
explainTerms(org.apache.calcite.rel.RelWriter pw) |
com.google.common.collect.ImmutableList<org.apache.calcite.rel.RelCollation> |
getCollation() |
Double |
getCumulativeMemoryWithinPhaseSplit() |
org.apache.calcite.rel.RelDistribution |
getDistribution() |
static HiveJoin |
getJoin(org.apache.calcite.plan.RelOptCluster cluster,
org.apache.calcite.rel.RelNode left,
org.apache.calcite.rel.RelNode right,
org.apache.calcite.rex.RexNode condition,
org.apache.calcite.rel.core.JoinRelType joinType,
boolean leftSemiJoin) |
HiveCostModel.JoinAlgorithm |
getJoinAlgorithm() |
HiveCalciteUtil.JoinPredicateInfo |
getJoinPredicateInfo() |
Double |
getMemory() |
org.apache.calcite.util.ImmutableBitSet |
getSortedInputs() |
Integer |
getSplitCount() |
org.apache.calcite.rel.RelNode |
getStreamingInput() |
HiveJoin.MapJoinStreamingRelation |
getStreamingSide() |
void |
implement(HiveRelNode.Implementor implementor) |
boolean |
isLeftSemiJoin() |
Boolean |
isPhaseTransition() |
void |
setJoinAlgorithm(HiveCostModel.JoinAlgorithm joinAlgorithm) |
void |
setJoinCost(org.apache.calcite.plan.RelOptCost joinCost) |
accept, analyzeCondition, copy, createJoinType, deriveJoinRowType, estimateJoinedRows, getChildExps, getCondition, getJoinType, getRows, getSystemFieldList, getVariablesStopped, isSemiJoinDone, isValid_
childrenAccept, getInputs, getLeft, getRight, replaceInput
accept, collectVariablesSet, collectVariablesUsed, computeDigest, explain, getCluster, getCollationList, getConvention, getCorrelVariable, getDescription, getDigest, getExpectedInputRowType, getId, getInput, getQuery, getRelTypeName, getRowType, getTable, getTraitSet, isDistinct, isKey, isValid, metadata, onRegister, recomputeDigest, register, sole, toString
clone, equals, finalize, getClass, hashCode, notify, notifyAll, wait, wait, wait
accept, accept, childrenAccept, collectVariablesSet, collectVariablesUsed, copy, explain, getChildExps, getCollationList, getConvention, getCorrelVariable, getExpectedInputRowType, getInput, getInputs, getQuery, getRelTypeName, getRows, getRowType, getTable, getVariablesStopped, isDistinct, isKey, isValid, metadata, onRegister, recomputeDigest, register, replaceInput
public static final org.apache.calcite.rel.core.RelFactories.JoinFactory HIVE_JOIN_FACTORY
protected HiveJoin(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.rex.RexNode condition, org.apache.calcite.rel.core.JoinRelType joinType, Set<String> variablesStopped, HiveCostModel.JoinAlgorithm joinAlgo, boolean leftSemiJoin) throws org.apache.calcite.rel.InvalidRelException
org.apache.calcite.rel.InvalidRelException
public static HiveJoin getJoin(org.apache.calcite.plan.RelOptCluster cluster, org.apache.calcite.rel.RelNode left, org.apache.calcite.rel.RelNode right, org.apache.calcite.rex.RexNode condition, org.apache.calcite.rel.core.JoinRelType joinType, boolean leftSemiJoin)
public void implement(HiveRelNode.Implementor implementor)
implement
in interface HiveRelNode
public final HiveJoin copy(org.apache.calcite.plan.RelTraitSet traitSet, org.apache.calcite.rex.RexNode conditionExpr, org.apache.calcite.rel.RelNode left, org.apache.calcite.rel.RelNode right, org.apache.calcite.rel.core.JoinRelType joinType, boolean semiJoinDone)
copy
in class org.apache.calcite.rel.core.Join
public HiveCalciteUtil.JoinPredicateInfo getJoinPredicateInfo()
public void setJoinAlgorithm(HiveCostModel.JoinAlgorithm joinAlgorithm)
public HiveCostModel.JoinAlgorithm getJoinAlgorithm()
public com.google.common.collect.ImmutableList<org.apache.calcite.rel.RelCollation> getCollation()
public org.apache.calcite.rel.RelDistribution getDistribution()
public Double getMemory()
public Double getCumulativeMemoryWithinPhaseSplit()
public Boolean isPhaseTransition()
public Integer getSplitCount()
public HiveJoin.MapJoinStreamingRelation getStreamingSide()
public org.apache.calcite.rel.RelNode getStreamingInput()
public org.apache.calcite.util.ImmutableBitSet getSortedInputs()
public void setJoinCost(org.apache.calcite.plan.RelOptCost joinCost)
public boolean isLeftSemiJoin()
public org.apache.calcite.plan.RelOptCost computeSelfCost(org.apache.calcite.plan.RelOptPlanner planner)
computeSelfCost
in interface org.apache.calcite.rel.RelNode
computeSelfCost
in class org.apache.calcite.rel.core.Join
public org.apache.calcite.rel.RelWriter explainTerms(org.apache.calcite.rel.RelWriter pw)
explainTerms
in class org.apache.calcite.rel.core.Join
public org.apache.calcite.rel.type.RelDataType deriveRowType()
deriveRowType
in class org.apache.calcite.rel.core.Join
Copyright © 2017 The Apache Software Foundation. All rights reserved.