public class BeamIOSourceRel extends org.apache.calcite.rel.core.TableScan implements BeamRelNode
TableScan
node.Constructor and Description |
---|
BeamIOSourceRel(org.apache.calcite.plan.RelOptCluster cluster,
org.apache.calcite.plan.RelOptTable table,
BeamSqlTable sqlTable,
java.util.Map<java.lang.String,java.lang.String> pipelineOptions) |
Modifier and Type | Method and Description |
---|---|
PTransform<PCollectionList<Row>,PCollection<Row>> |
buildPTransform() |
protected 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, computeSelfCost, deriveRowType, estimateRowCount, 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, 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 BeamIOSourceRel(org.apache.calcite.plan.RelOptCluster cluster, org.apache.calcite.plan.RelOptTable table, BeamSqlTable sqlTable, java.util.Map<java.lang.String,java.lang.String> pipelineOptions)
public PCollection.IsBounded isBounded()
BeamRelNode
isBounded
in interface BeamRelNode
public PTransform<PCollectionList<Row>,PCollection<Row>> buildPTransform()
buildPTransform
in interface BeamRelNode
protected BeamSqlTable getBeamSqlTable()
public java.util.Map<java.lang.String,java.lang.String> getPipelineOptions()
BeamRelNode
getPipelineOptions
in interface BeamRelNode