public class BatchExecLegacyTableSourceScan extends CommonExecLegacyTableSourceScan implements BatchExecNode<RowData>
ExecNode
to read data from an external source defined by a bounded StreamTableSource
.qualifiedName, tableSource
FIELD_NAME_CONFIGURATION, FIELD_NAME_DESCRIPTION, FIELD_NAME_ID, FIELD_NAME_INPUT_PROPERTIES, FIELD_NAME_OUTPUT_TYPE, FIELD_NAME_TYPE
Constructor and Description |
---|
BatchExecLegacyTableSourceScan(ReadableConfig tableConfig,
TableSource<?> tableSource,
List<String> qualifiedName,
RowType outputType,
String description) |
Modifier and Type | Method and Description |
---|---|
protected Transformation<RowData> |
createConversionTransformationIfNeeded(StreamExecutionEnvironment streamExecEnv,
ExecNodeConfig config,
ClassLoader classLoader,
Transformation<?> sourceTransform,
org.apache.calcite.rex.RexNode rowtimeExpression) |
protected <IN> Transformation<IN> |
createInput(StreamExecutionEnvironment env,
InputFormat<IN,? extends InputSplit> inputFormat,
TypeInformation<IN> typeInfo) |
protected Transformation<RowData> |
translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config)
Internal method, translates this node into a Flink operator.
|
computeIndexMapping, needInternalConversion
accept, createFormattedTransformationDescription, createFormattedTransformationName, createTransformationDescription, createTransformationMeta, createTransformationMeta, createTransformationName, createTransformationUid, getContextFromAnnotation, getDescription, getId, getInputEdges, getInputProperties, getOutputType, getPersistedConfig, getSimplifiedName, getTransformation, inputsContainSingleton, replaceInputEdge, resetTransformation, setCompiled, setInputEdges, translateToPlan
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
accept, getDescription, getId, getInputEdges, getInputProperties, getOutputType, replaceInputEdge, setCompiled, setInputEdges
translateToPlan
public BatchExecLegacyTableSourceScan(ReadableConfig tableConfig, TableSource<?> tableSource, List<String> qualifiedName, RowType outputType, String description)
protected Transformation<RowData> translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config)
ExecNodeBase
translateToPlanInternal
in class CommonExecLegacyTableSourceScan
planner
- The planner.config
- per-ExecNode
configuration that contains the merged configuration from
various layers which all the nodes implementing this method should use, instead of
retrieving configuration from the planner
. For more details check ExecNodeConfig
.protected Transformation<RowData> createConversionTransformationIfNeeded(StreamExecutionEnvironment streamExecEnv, ExecNodeConfig config, ClassLoader classLoader, Transformation<?> sourceTransform, @Nullable org.apache.calcite.rex.RexNode rowtimeExpression)
createConversionTransformationIfNeeded
in class CommonExecLegacyTableSourceScan
protected <IN> Transformation<IN> createInput(StreamExecutionEnvironment env, InputFormat<IN,? extends InputSplit> inputFormat, TypeInformation<IN> typeInfo)
createInput
in class CommonExecLegacyTableSourceScan
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.