@Internal public class BeamZetaSqlCalcRel extends AbstractBeamCalcRel
Project
and Filter
node based on the ZetaSQL
expression evaluator.hints, program
Constructor and Description |
---|
BeamZetaSqlCalcRel(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 traits,
org.apache.beam.vendor.calcite.v1_28_0.org.apache.calcite.rel.RelNode input,
org.apache.beam.vendor.calcite.v1_28_0.org.apache.calcite.rex.RexProgram program) |
Modifier and Type | Method and Description |
---|---|
PTransform<PCollectionList<Row>,PCollection<Row>> |
buildPTransform() |
PTransform<PCollectionList<Row>,PCollection<Row>> |
buildPTransform(@Nullable PTransform<PCollection<Row>,? extends POutput> errorsTransformer) |
org.apache.beam.vendor.calcite.v1_28_0.org.apache.calcite.rel.core.Calc |
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,
org.apache.beam.vendor.calcite.v1_28_0.org.apache.calcite.rex.RexProgram program) |
beamComputeSelfCost, deepEquals, estimateNodeStats, getLimitCountOfSortRel, isInputSortRelAndLimitOnly
accept, computeSelfCost, containsOver, copy, copy, estimateRowCount, explainTerms, getHints, getProgram, isValid
childrenAccept, deriveRowType, getInput, getInputs, replaceInput
accept, collectVariablesSet, collectVariablesUsed, 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
getPCollectionInputs, getPipelineOptions, isBounded, withErrorsTransformer
accept, accept, childrenAccept, collectVariablesSet, collectVariablesUsed, computeSelfCost, copy, deepHashCode, estimateRowCount, explain, explain, fieldIsNullable, getConvention, getCorrelVariable, getDigest, getExpectedInputRowType, getInput, getInputs, getRelDigest, getRelTypeName, getRowType, getTable, getVariablesSet, isEnforcer, isValid, metadata, onRegister, recomputeDigest, register, replaceInput
public BeamZetaSqlCalcRel(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 traits, org.apache.beam.vendor.calcite.v1_28_0.org.apache.calcite.rel.RelNode input, org.apache.beam.vendor.calcite.v1_28_0.org.apache.calcite.rex.RexProgram program)
public org.apache.beam.vendor.calcite.v1_28_0.org.apache.calcite.rel.core.Calc 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, org.apache.beam.vendor.calcite.v1_28_0.org.apache.calcite.rex.RexProgram program)
copy
in class org.apache.beam.vendor.calcite.v1_28_0.org.apache.calcite.rel.core.Calc
public PTransform<PCollectionList<Row>,PCollection<Row>> buildPTransform()
public PTransform<PCollectionList<Row>,PCollection<Row>> buildPTransform(@Nullable PTransform<PCollection<Row>,? extends POutput> errorsTransformer)