public class BeamAggregationRel extends org.apache.calcite.rel.core.Aggregate implements BeamRelNode
BeamRelNode
to replace a Aggregate
node.Constructor and Description |
---|
BeamAggregationRel(org.apache.calcite.plan.RelOptCluster cluster,
org.apache.calcite.plan.RelTraitSet traits,
org.apache.calcite.rel.RelNode child,
boolean indicator,
org.apache.calcite.util.ImmutableBitSet groupSet,
java.util.List<org.apache.calcite.util.ImmutableBitSet> groupSets,
java.util.List<org.apache.calcite.rel.core.AggregateCall> aggCalls,
WindowFn<Row,IntervalWindow> windowFn,
int windowFieldIndex) |
Modifier and Type | Method and Description |
---|---|
PTransform<PCollectionList<Row>,PCollection<Row>> |
buildPTransform() |
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,
java.util.List<org.apache.calcite.util.ImmutableBitSet> groupSets,
java.util.List<org.apache.calcite.rel.core.AggregateCall> aggCalls) |
org.apache.calcite.rel.RelWriter |
explainTerms(org.apache.calcite.rel.RelWriter pw) |
computeSelfCost, containsDistinctCall, copy, deriveRowType, deriveRowType, estimateRowCount, getAggCallList, getGroupCount, getGroupSet, getGroupSets, getGroupType, getIndicatorCount, getNamedAggCalls, isNotGrandTotal, isSimple, isValid, noIndicator
childrenAccept, getInput, getInputs, replaceInput
accept, accept, collectVariablesSet, collectVariablesUsed, computeDigest, computeSelfCost, explain, getChildExps, getCluster, getCollationList, getConvention, getCorrelVariable, getDescription, getDigest, getExpectedInputRowType, getId, getInput, getQuery, getRelTypeName, getRows, getRowType, getTable, getTraitSet, getVariablesSet, getVariablesStopped, isDistinct, isKey, isValid, metadata, onRegister, recomputeDigest, register, sole, toString
clone, equals, finalize, getClass, hashCode, notify, notifyAll, wait, wait, wait
getPCollectionInputs, getPipelineOptions, isBounded
accept, accept, childrenAccept, collectVariablesSet, collectVariablesUsed, computeSelfCost, computeSelfCost, copy, estimateRowCount, explain, getChildExps, getCollationList, getConvention, getCorrelVariable, getExpectedInputRowType, getInput, getInputs, getQuery, getRelTypeName, getRows, getRowType, getTable, getVariablesSet, getVariablesStopped, isDistinct, isKey, isValid, isValid, metadata, onRegister, recomputeDigest, register, replaceInput
public BeamAggregationRel(org.apache.calcite.plan.RelOptCluster cluster, org.apache.calcite.plan.RelTraitSet traits, org.apache.calcite.rel.RelNode child, boolean indicator, org.apache.calcite.util.ImmutableBitSet groupSet, java.util.List<org.apache.calcite.util.ImmutableBitSet> groupSets, java.util.List<org.apache.calcite.rel.core.AggregateCall> aggCalls, @Nullable WindowFn<Row,IntervalWindow> windowFn, int windowFieldIndex)
public org.apache.calcite.rel.RelWriter explainTerms(org.apache.calcite.rel.RelWriter pw)
explainTerms
in class org.apache.calcite.rel.core.Aggregate
public PTransform<PCollectionList<Row>,PCollection<Row>> buildPTransform()
buildPTransform
in interface BeamRelNode
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, java.util.List<org.apache.calcite.util.ImmutableBitSet> groupSets, java.util.List<org.apache.calcite.rel.core.AggregateCall> aggCalls)
copy
in class org.apache.calcite.rel.core.Aggregate