public class BeamPushDownIOSourceRel extends BeamIOSourceRel
CONSTANT_WINDOW_SIZE| Constructor and Description | 
|---|
| BeamPushDownIOSourceRel(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 traitSet,
                       org.apache.beam.vendor.calcite.v1_20_0.org.apache.calcite.plan.RelOptTable table,
                       BeamSqlTable beamTable,
                       java.util.List<java.lang.String> usedFields,
                       BeamSqlTableFilter tableFilters,
                       java.util.Map<java.lang.String,java.lang.String> pipelineOptions,
                       BeamCalciteTable calciteTable) | 
| Modifier and Type | Method and Description | 
|---|---|
| BeamCostModel | beamComputeSelfCost(org.apache.beam.vendor.calcite.v1_20_0.org.apache.calcite.plan.RelOptPlanner planner,
                   org.apache.beam.vendor.calcite.v1_20_0.org.apache.calcite.rel.metadata.RelMetadataQuery mq)This method is called by  org.apache.beam.sdk.extensions.sql.impl.CalciteQueryPlanner.NonCumulativeCostImpl. | 
| PTransform<PCollectionList<Row>,PCollection<Row>> | buildPTransform() | 
| org.apache.beam.vendor.calcite.v1_20_0.org.apache.calcite.rel.RelWriter | explainTerms(org.apache.beam.vendor.calcite.v1_20_0.org.apache.calcite.rel.RelWriter pw) | 
computeSelfCost, createPushDownRel, estimateNodeStats, estimateRowCount, getBeamSqlTable, getPipelineOptions, isBoundedaccept, deriveRowType, getCollationList, getTable, identity, identity, projectaccept, childrenAccept, collectVariablesSet, collectVariablesUsed, computeDigest, computeSelfCost, copy, explain, getChildExps, getCluster, getConvention, getCorrelVariable, getDescription, getDigest, getExpectedInputRowType, getId, getInput, getInputs, getQuery, getRelTypeName, getRows, getRowType, getTraitSet, getVariablesSet, getVariablesStopped, isDistinct, isKey, isValid, isValid, metadata, onRegister, recomputeDigest, register, replaceInput, sole, toStringclone, equals, finalize, getClass, hashCode, notify, notifyAll, wait, wait, waitgetPCollectionInputsaccept, accept, childrenAccept, collectVariablesSet, collectVariablesUsed, computeSelfCost, copy, explain, getChildExps, getCollationList, getConvention, getCorrelVariable, getExpectedInputRowType, getInput, getInputs, getQuery, getRelTypeName, getRows, getRowType, getTable, getVariablesSet, getVariablesStopped, isDistinct, isKey, isValid, isValid, metadata, onRegister, recomputeDigest, register, replaceInputpublic BeamPushDownIOSourceRel(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 traitSet,
                               org.apache.beam.vendor.calcite.v1_20_0.org.apache.calcite.plan.RelOptTable table,
                               BeamSqlTable beamTable,
                               java.util.List<java.lang.String> usedFields,
                               BeamSqlTableFilter tableFilters,
                               java.util.Map<java.lang.String,java.lang.String> pipelineOptions,
                               BeamCalciteTable calciteTable)
public org.apache.beam.vendor.calcite.v1_20_0.org.apache.calcite.rel.RelWriter explainTerms(org.apache.beam.vendor.calcite.v1_20_0.org.apache.calcite.rel.RelWriter pw)
explainTerms in class org.apache.beam.vendor.calcite.v1_20_0.org.apache.calcite.rel.core.TableScanpublic PTransform<PCollectionList<Row>,PCollection<Row>> buildPTransform()
buildPTransform in interface BeamRelNodebuildPTransform in class BeamIOSourceRelpublic BeamCostModel beamComputeSelfCost(org.apache.beam.vendor.calcite.v1_20_0.org.apache.calcite.plan.RelOptPlanner planner, org.apache.beam.vendor.calcite.v1_20_0.org.apache.calcite.rel.metadata.RelMetadataQuery mq)
BeamRelNodeorg.apache.beam.sdk.extensions.sql.impl.CalciteQueryPlanner.NonCumulativeCostImpl. This is
 currently only used in SQLTransform Path (and not JDBC path). This is needed when Calcite Query
 Planner wants to get the cost of a plan. Instead of calling this directly for a node, if we
 needed that it should be obtained by calling mq.getNonCumulativeCost. This way RelMetadataQuery
 will call this method instead of ComputeSelfCost if the handler is set correctly (see org.apache.beam.sdk.extensions.sql.impl.CalciteQueryPlanner#convertToBeamRel(String))beamComputeSelfCost in interface BeamRelNodebeamComputeSelfCost in class BeamIOSourceRel