Class BeamZetaSqlCalcRel

java.lang.Object
org.apache.beam.vendor.calcite.v1_28_0.org.apache.calcite.rel.AbstractRelNode
org.apache.beam.vendor.calcite.v1_28_0.org.apache.calcite.rel.SingleRel
org.apache.beam.vendor.calcite.v1_28_0.org.apache.calcite.rel.core.Calc
org.apache.beam.sdk.extensions.sql.impl.rel.AbstractBeamCalcRel
org.apache.beam.sdk.extensions.sql.zetasql.BeamZetaSqlCalcRel
All Implemented Interfaces:
Cloneable, BeamRelNode, org.apache.beam.vendor.calcite.v1_28_0.org.apache.calcite.plan.RelOptNode, org.apache.beam.vendor.calcite.v1_28_0.org.apache.calcite.rel.hint.Hintable, org.apache.beam.vendor.calcite.v1_28_0.org.apache.calcite.rel.RelNode

@Internal public class BeamZetaSqlCalcRel extends AbstractBeamCalcRel
BeamRelNode to replace Project and Filter node based on the ZetaSQL expression evaluator.
  • Nested Class Summary

    Nested classes/interfaces inherited from interface 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.RelNode.Context
  • Field Summary

    Fields inherited from class org.apache.beam.vendor.calcite.v1_28_0.org.apache.calcite.rel.core.Calc

    hints, program

    Fields inherited from class org.apache.beam.vendor.calcite.v1_28_0.org.apache.calcite.rel.SingleRel

    input

    Fields inherited from class org.apache.beam.vendor.calcite.v1_28_0.org.apache.calcite.rel.AbstractRelNode

    digest, id, rowType, traitSet
  • Constructor Summary

    Constructors
    Constructor
    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)
     
  • Method Summary

    Modifier and Type
    Method
    Description
     
    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)
     

    Methods inherited from class org.apache.beam.sdk.extensions.sql.impl.rel.AbstractBeamCalcRel

    beamComputeSelfCost, deepEquals, estimateNodeStats, getLimitCountOfSortRel, isInputSortRelAndLimitOnly

    Methods inherited from class org.apache.beam.vendor.calcite.v1_28_0.org.apache.calcite.rel.core.Calc

    accept, computeSelfCost, containsOver, copy, copy, estimateRowCount, explainTerms, getHints, getProgram, isValid

    Methods inherited from class org.apache.beam.vendor.calcite.v1_28_0.org.apache.calcite.rel.SingleRel

    childrenAccept, deriveRowType, getInput, getInputs, replaceInput

    Methods inherited from class org.apache.beam.vendor.calcite.v1_28_0.org.apache.calcite.rel.AbstractRelNode

    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

    Methods inherited from class java.lang.Object

    clone, finalize, getClass, notify, notifyAll, wait, wait, wait

    Methods inherited from interface org.apache.beam.sdk.extensions.sql.impl.rel.BeamRelNode

    getPCollectionInputs, getPipelineOptions, isBounded, withErrorsTransformer

    Methods inherited from interface org.apache.beam.vendor.calcite.v1_28_0.org.apache.calcite.rel.hint.Hintable

    attachHints, withHints

    Methods inherited from interface org.apache.beam.vendor.calcite.v1_28_0.org.apache.calcite.rel.RelNode

    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

    Methods inherited from interface org.apache.beam.vendor.calcite.v1_28_0.org.apache.calcite.plan.RelOptNode

    getCluster, getDescription, getId, getTraitSet
  • Constructor Details

    • BeamZetaSqlCalcRel

      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)
  • Method Details

    • copy

      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)
      Specified by:
      copy in class org.apache.beam.vendor.calcite.v1_28_0.org.apache.calcite.rel.core.Calc
    • buildPTransform

      public PTransform<PCollectionList<Row>,PCollection<Row>> buildPTransform()
    • buildPTransform

      public PTransform<PCollectionList<Row>,PCollection<Row>> buildPTransform(@Nullable PTransform<PCollection<Row>,? extends POutput> errorsTransformer)