public class BeamCalcRel extends AbstractBeamCalcRel
Project
and Filter
node.Modifier and Type | Class and Description |
---|---|
static class |
BeamCalcRel.WrappedList<T>
WrappedList translates
List on access. |
static class |
BeamCalcRel.WrappedMap<V>
WrappedMap translates
Map on access. |
static class |
BeamCalcRel.WrappedRow
WrappedRow translates
Row on access. |
program
Constructor and Description |
---|
BeamCalcRel(org.apache.beam.vendor.calcite.v1_20_0.org.apache.calcite.plan.RelOptCluster cluster,
org.apache.beam.vendor.calcite.v1_20_0.org.apache.calcite.plan.RelTraitSet traits,
org.apache.beam.vendor.calcite.v1_20_0.org.apache.calcite.rel.RelNode input,
org.apache.beam.vendor.calcite.v1_20_0.org.apache.calcite.rex.RexProgram program) |
Modifier and Type | Method and Description |
---|---|
PTransform<PCollectionList<Row>,PCollection<Row>> |
buildPTransform() |
org.apache.beam.vendor.calcite.v1_20_0.org.apache.calcite.rel.core.Calc |
copy(org.apache.beam.vendor.calcite.v1_20_0.org.apache.calcite.plan.RelTraitSet traitSet,
org.apache.beam.vendor.calcite.v1_20_0.org.apache.calcite.rel.RelNode input,
org.apache.beam.vendor.calcite.v1_20_0.org.apache.calcite.rex.RexProgram program) |
beamComputeSelfCost, estimateNodeStats, getLimitCountOfSortRel, isInputSortRelAndLimitOnly
accept, computeSelfCost, copy, copy, estimateRowCount, explainTerms, getProgram, isValid
childrenAccept, deriveRowType, getInput, getInputs, replaceInput
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 BeamCalcRel(org.apache.beam.vendor.calcite.v1_20_0.org.apache.calcite.plan.RelOptCluster cluster, org.apache.beam.vendor.calcite.v1_20_0.org.apache.calcite.plan.RelTraitSet traits, org.apache.beam.vendor.calcite.v1_20_0.org.apache.calcite.rel.RelNode input, org.apache.beam.vendor.calcite.v1_20_0.org.apache.calcite.rex.RexProgram program)
public org.apache.beam.vendor.calcite.v1_20_0.org.apache.calcite.rel.core.Calc copy(org.apache.beam.vendor.calcite.v1_20_0.org.apache.calcite.plan.RelTraitSet traitSet, org.apache.beam.vendor.calcite.v1_20_0.org.apache.calcite.rel.RelNode input, org.apache.beam.vendor.calcite.v1_20_0.org.apache.calcite.rex.RexProgram program)
copy
in class org.apache.beam.vendor.calcite.v1_20_0.org.apache.calcite.rel.core.Calc
public PTransform<PCollectionList<Row>,PCollection<Row>> buildPTransform()