public class HiveAggregate extends org.apache.calcite.rel.core.Aggregate implements HiveRelNode
org.apache.calcite.rel.core.Aggregate.AggCallBinding, org.apache.calcite.rel.core.Aggregate.Group
HiveRelNode.Implementor
Modifier and Type | Field and Description |
---|---|
static org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveAggregate.HiveAggRelFactory |
HIVE_AGGR_REL_FACTORY |
aggCalls, groupSet, groupSets, indicator, IS_SIMPLE
CONVENTION
Constructor and Description |
---|
HiveAggregate(org.apache.calcite.plan.RelOptCluster cluster,
org.apache.calcite.plan.RelTraitSet traitSet,
org.apache.calcite.rel.RelNode child,
boolean indicator,
org.apache.calcite.util.ImmutableBitSet groupSet,
List<org.apache.calcite.util.ImmutableBitSet> groupSets,
List<org.apache.calcite.rel.core.AggregateCall> aggCalls) |
Modifier and Type | Method and Description |
---|---|
org.apache.calcite.plan.RelOptCost |
computeSelfCost(org.apache.calcite.plan.RelOptPlanner planner) |
org.apache.calcite.rel.core.Aggregate |
copy(org.apache.calcite.plan.RelTraitSet traitSet,
org.apache.calcite.rel.RelNode input,
boolean indicator,
org.apache.calcite.util.ImmutableBitSet groupSet,
List<org.apache.calcite.util.ImmutableBitSet> groupSets,
List<org.apache.calcite.rel.core.AggregateCall> aggCalls) |
protected org.apache.calcite.rel.type.RelDataType |
deriveRowType() |
static org.apache.calcite.rel.type.RelDataType |
deriveRowType(org.apache.calcite.rel.type.RelDataTypeFactory typeFactory,
org.apache.calcite.rel.type.RelDataType inputRowType,
boolean indicator,
org.apache.calcite.util.ImmutableBitSet groupSet,
List<org.apache.calcite.util.ImmutableBitSet> groupSets,
List<org.apache.calcite.rel.core.AggregateCall> aggCalls) |
double |
getRows() |
void |
implement(HiveRelNode.Implementor implementor) |
boolean |
isBucketedInput() |
containsDistinctCall, copy, explainTerms, getAggCallList, getGroupCount, getGroupSet, getGroupSets, getGroupType, getIndicatorCount, isDistinct
childrenAccept, getInput, getInputs, replaceInput
accept, accept, collectVariablesSet, collectVariablesUsed, computeDigest, explain, getChildExps, getCluster, getCollationList, getConvention, getCorrelVariable, getDescription, getDigest, getExpectedInputRowType, getId, getInput, getQuery, getRelTypeName, getRowType, getTable, getTraitSet, getVariablesStopped, 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, getRowType, getTable, getVariablesStopped, isDistinct, isKey, isValid, metadata, onRegister, recomputeDigest, register, replaceInput
public static final org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveAggregate.HiveAggRelFactory HIVE_AGGR_REL_FACTORY
public HiveAggregate(org.apache.calcite.plan.RelOptCluster cluster, org.apache.calcite.plan.RelTraitSet traitSet, org.apache.calcite.rel.RelNode child, boolean indicator, org.apache.calcite.util.ImmutableBitSet groupSet, List<org.apache.calcite.util.ImmutableBitSet> groupSets, List<org.apache.calcite.rel.core.AggregateCall> aggCalls) throws org.apache.calcite.rel.InvalidRelException
org.apache.calcite.rel.InvalidRelException
public org.apache.calcite.rel.core.Aggregate copy(org.apache.calcite.plan.RelTraitSet traitSet, org.apache.calcite.rel.RelNode input, boolean indicator, org.apache.calcite.util.ImmutableBitSet groupSet, List<org.apache.calcite.util.ImmutableBitSet> groupSets, List<org.apache.calcite.rel.core.AggregateCall> aggCalls)
copy
in class org.apache.calcite.rel.core.Aggregate
public void implement(HiveRelNode.Implementor implementor)
implement
in interface HiveRelNode
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.Aggregate
public double getRows()
getRows
in interface org.apache.calcite.rel.RelNode
getRows
in class org.apache.calcite.rel.core.Aggregate
public boolean isBucketedInput()
protected org.apache.calcite.rel.type.RelDataType deriveRowType()
deriveRowType
in class org.apache.calcite.rel.core.Aggregate
public static org.apache.calcite.rel.type.RelDataType deriveRowType(org.apache.calcite.rel.type.RelDataTypeFactory typeFactory, org.apache.calcite.rel.type.RelDataType inputRowType, boolean indicator, org.apache.calcite.util.ImmutableBitSet groupSet, List<org.apache.calcite.util.ImmutableBitSet> groupSets, List<org.apache.calcite.rel.core.AggregateCall> aggCalls)
Copyright © 2017 The Apache Software Foundation. All rights reserved.