public class BeamIOSourceRel extends org.apache.beam.vendor.calcite.v1_20_0.org.apache.calcite.rel.core.TableScan implements BeamRelNode
TableScan
node.Modifier and Type | Field and Description |
---|---|
static double |
CONSTANT_WINDOW_SIZE |
Constructor and Description |
---|
BeamIOSourceRel(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.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.plan.RelOptCost |
computeSelfCost(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) |
BeamPushDownIOSourceRel |
createPushDownRel(org.apache.beam.vendor.calcite.v1_20_0.org.apache.calcite.rel.type.RelDataType newType,
java.util.List<java.lang.String> usedFields,
BeamSqlTableFilter tableFilters) |
NodeStats |
estimateNodeStats(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.planner.RelMdNodeStats . |
double |
estimateRowCount(org.apache.beam.vendor.calcite.v1_20_0.org.apache.calcite.rel.metadata.RelMetadataQuery mq) |
BeamSqlTable |
getBeamSqlTable() |
java.util.Map<java.lang.String,java.lang.String> |
getPipelineOptions()
Perform a DFS(Depth-First-Search) to find the PipelineOptions config.
|
PCollection.IsBounded |
isBounded()
Whether the collection of rows represented by this relational expression is bounded (known to
be finite) or unbounded (may or may not be finite).
|
accept, deriveRowType, explainTerms, getCollationList, getTable, identity, identity, project
accept, 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, toString
clone, equals, finalize, getClass, hashCode, notify, notifyAll, wait, wait, wait
getPCollectionInputs
accept, 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, replaceInput
public static final double CONSTANT_WINDOW_SIZE
public BeamIOSourceRel(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.Map<java.lang.String,java.lang.String> pipelineOptions, BeamCalciteTable calciteTable)
public BeamPushDownIOSourceRel createPushDownRel(org.apache.beam.vendor.calcite.v1_20_0.org.apache.calcite.rel.type.RelDataType newType, java.util.List<java.lang.String> usedFields, BeamSqlTableFilter tableFilters)
public double estimateRowCount(org.apache.beam.vendor.calcite.v1_20_0.org.apache.calcite.rel.metadata.RelMetadataQuery mq)
estimateRowCount
in interface org.apache.beam.vendor.calcite.v1_20_0.org.apache.calcite.rel.RelNode
estimateRowCount
in class org.apache.beam.vendor.calcite.v1_20_0.org.apache.calcite.rel.core.TableScan
public NodeStats estimateNodeStats(org.apache.beam.vendor.calcite.v1_20_0.org.apache.calcite.rel.metadata.RelMetadataQuery 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 BeamSqlRelUtils.getNodeStats(
org.apache.beam.vendor.calcite.v1_20_0.org.apache.calcite.rel.RelNode,
org.apache.beam.vendor.calcite.v1_20_0.org.apache.calcite.rel.metadata.RelMetadataQuery)
instead.estimateNodeStats
in interface BeamRelNode
public PCollection.IsBounded isBounded()
BeamRelNode
isBounded
in interface BeamRelNode
public PTransform<PCollectionList<Row>,PCollection<Row>> buildPTransform()
buildPTransform
in interface BeamRelNode
public org.apache.beam.vendor.calcite.v1_20_0.org.apache.calcite.plan.RelOptCost computeSelfCost(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)
computeSelfCost
in interface org.apache.beam.vendor.calcite.v1_20_0.org.apache.calcite.rel.RelNode
computeSelfCost
in class org.apache.beam.vendor.calcite.v1_20_0.org.apache.calcite.rel.core.TableScan
public 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)
BeamRelNode
org.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 BeamRelNode
public BeamSqlTable getBeamSqlTable()
public java.util.Map<java.lang.String,java.lang.String> getPipelineOptions()
BeamRelNode
getPipelineOptions
in interface BeamRelNode