public class BeamWindowRel extends org.apache.beam.vendor.calcite.v1_28_0.org.apache.calcite.rel.core.Window implements BeamRelNode
BeamRelNode
to replace a Window
node.
The following types of Analytic Functions are supported:
SELECT agg(c) over () FROM t
SELECT agg(c1) over (PARTITION BY c2 ORDER BY c3 ROWS BETWEEN UNBOUNDED PRECEDING AND CURRENT ROW) FROM t
SELECT agg(c1) over (PARTITION BY c2 ORDER BY c3 RANGE BETWEEN 1 PRECEDING AND 1 FOLLOWING) FROM t
constants, groups
Constructor and Description |
---|
BeamWindowRel(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 input,
java.util.List<org.apache.beam.vendor.calcite.v1_28_0.org.apache.calcite.rex.RexLiteral> constants,
org.apache.beam.vendor.calcite.v1_28_0.org.apache.calcite.rel.type.RelDataType rowType,
java.util.List<org.apache.beam.vendor.calcite.v1_28_0.org.apache.calcite.rel.core.Window.Group> groups) |
Modifier and Type | Method and Description |
---|---|
BeamCostModel |
beamComputeSelfCost(org.apache.beam.vendor.calcite.v1_28_0.org.apache.calcite.plan.RelOptPlanner planner,
BeamRelMetadataQuery mq)
A dummy cost computation based on a fixed multiplier.
|
PTransform<PCollectionList<Row>,PCollection<Row>> |
buildPTransform() |
org.apache.beam.vendor.calcite.v1_28_0.org.apache.calcite.rel.RelNode |
copy(org.apache.beam.vendor.calcite.v1_28_0.org.apache.calcite.plan.RelTraitSet traitSet,
java.util.List<org.apache.beam.vendor.calcite.v1_28_0.org.apache.calcite.rel.RelNode> inputs) |
BeamWindowRel |
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.rel.RelNode input,
java.util.List<org.apache.beam.vendor.calcite.v1_28_0.org.apache.calcite.rex.RexLiteral> constants,
org.apache.beam.vendor.calcite.v1_28_0.org.apache.calcite.rel.type.RelDataType rowType,
java.util.List<org.apache.beam.vendor.calcite.v1_28_0.org.apache.calcite.rel.core.Window.Group> groups) |
NodeStats |
estimateNodeStats(BeamRelMetadataQuery mq)
This method is called by
org.apache.beam.sdk.extensions.sql.impl.planner.RelMdNodeStats . |
computeSelfCost, explainTerms, getCollation, getConstants, getProjectOrdinals, isValid
childrenAccept, deriveRowType, estimateRowCount, getInput, getInputs, replaceInput
accept, accept, collectVariablesSet, collectVariablesUsed, deepEquals, deepHashCode, equals, explain, getCluster, getConvention, getCorrelVariable, getDescription, getDigest, getExpectedInputRowType, getId, getInput, getRelDigest, getRelTypeName, getRowType, getTable, getTraitSet, getVariablesSet, hashCode, isEnforcer, metadata, onRegister, recomputeDigest, register, sole, toString
clone, finalize, getClass, notify, notifyAll, wait, wait, wait
buildPTransform, getPCollectionInputs, getPipelineOptions, isBounded, withErrorsTransformer
accept, accept, childrenAccept, collectVariablesSet, collectVariablesUsed, computeSelfCost, 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 BeamWindowRel(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 input, java.util.List<org.apache.beam.vendor.calcite.v1_28_0.org.apache.calcite.rex.RexLiteral> constants, org.apache.beam.vendor.calcite.v1_28_0.org.apache.calcite.rel.type.RelDataType rowType, java.util.List<org.apache.beam.vendor.calcite.v1_28_0.org.apache.calcite.rel.core.Window.Group> groups)
public PTransform<PCollectionList<Row>,PCollection<Row>> buildPTransform()
buildPTransform
in interface BeamRelNode
public NodeStats estimateNodeStats(BeamRelMetadataQuery mq)
BeamRelNode
org.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 call org.apache.beam.sdk.extensions.sql.impl.rel.BeamSqlRelUtils#getNodeStats(
org.apache.beam.vendor.calcite.v1_28_0.org.apache.calcite.rel.RelNode,
org.apache.beam.vendor.calcite.v1_28_0.org.apache.calcite.rel.metadata.RelMetadataQuery)
instead.estimateNodeStats
in interface BeamRelNode
public BeamCostModel beamComputeSelfCost(org.apache.beam.vendor.calcite.v1_28_0.org.apache.calcite.plan.RelOptPlanner planner, BeamRelMetadataQuery mq)
Since, there are not additional LogicalWindow to BeamWindowRel strategies, the result of this cost computation has no impact in the query execution plan.
beamComputeSelfCost
in interface BeamRelNode
public org.apache.beam.vendor.calcite.v1_28_0.org.apache.calcite.rel.RelNode copy(org.apache.beam.vendor.calcite.v1_28_0.org.apache.calcite.plan.RelTraitSet traitSet, java.util.List<org.apache.beam.vendor.calcite.v1_28_0.org.apache.calcite.rel.RelNode> inputs)
copy
in interface org.apache.beam.vendor.calcite.v1_28_0.org.apache.calcite.rel.RelNode
copy
in class org.apache.beam.vendor.calcite.v1_28_0.org.apache.calcite.rel.AbstractRelNode
public BeamWindowRel 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.rel.RelNode input, java.util.List<org.apache.beam.vendor.calcite.v1_28_0.org.apache.calcite.rex.RexLiteral> constants, org.apache.beam.vendor.calcite.v1_28_0.org.apache.calcite.rel.type.RelDataType rowType, java.util.List<org.apache.beam.vendor.calcite.v1_28_0.org.apache.calcite.rel.core.Window.Group> groups)