public class BatchExecTableSourceScan extends CommonExecTableSourceScan implements BatchExecNode<RowData>
ExecNode
to read data from an external source defined by a bounded ScanTableSource
.FIELD_NAME_SCAN_TABLE_SOURCE, SOURCE_TRANSFORMATION
FIELD_NAME_CONFIGURATION, FIELD_NAME_DESCRIPTION, FIELD_NAME_ID, FIELD_NAME_INPUT_PROPERTIES, FIELD_NAME_OUTPUT_TYPE, FIELD_NAME_STATE, FIELD_NAME_TYPE
Constructor and Description |
---|
BatchExecTableSourceScan(ReadableConfig tableConfig,
DynamicTableSourceSpec tableSourceSpec,
InputProperty inputProperty,
RowType outputType,
String description) |
BatchExecTableSourceScan(ReadableConfig tableConfig,
DynamicTableSourceSpec tableSourceSpec,
RowType outputType,
String description) |
Modifier and Type | Method and Description |
---|---|
BatchExecTableSourceScan |
copyAndRemoveInputs() |
Transformation<RowData> |
createInputFormatTransformation(StreamExecutionEnvironment env,
InputFormat<RowData,?> inputFormat,
InternalTypeInfo<RowData> outputTypeInfo,
String operatorName)
Creates a
Transformation based on the given InputFormat . |
static BatchExecDynamicFilteringDataCollector |
getDynamicFilteringDataCollector(BatchExecNode<?> node) |
String |
getDynamicFilteringDataListenerID() |
protected Transformation<RowData> |
translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config)
Internal method, translates this node into a Flink operator.
|
createSourceFunctionTransformation, getPhysicalRowType, getPrimaryKeyIndices, getSimplifiedName, getTableSourceSpec
accept, createFormattedTransformationDescription, createFormattedTransformationName, createTransformationDescription, createTransformationMeta, createTransformationMeta, createTransformationName, createTransformationUid, getContextFromAnnotation, getDescription, getId, getInputEdges, getInputProperties, getOutputType, getPersistedConfig, getTransformation, inputsContainSingleton, replaceInputEdge, setCompiled, setInputEdges, supportFusionCodegen, translateToFusionCodegenSpec, translateToFusionCodegenSpecInternal, translateToPlan
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
accept, getDescription, getId, getInputEdges, getInputProperties, getOutputType, replaceInputEdge, setCompiled, setInputEdges
translateToPlan
supportFusionCodegen, translateToFusionCodegenSpec
public BatchExecTableSourceScan(ReadableConfig tableConfig, DynamicTableSourceSpec tableSourceSpec, InputProperty inputProperty, RowType outputType, String description)
public BatchExecTableSourceScan(ReadableConfig tableConfig, DynamicTableSourceSpec tableSourceSpec, RowType outputType, String description)
public String getDynamicFilteringDataListenerID()
protected Transformation<RowData> translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config)
ExecNodeBase
translateToPlanInternal
in class CommonExecTableSourceScan
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
.public static BatchExecDynamicFilteringDataCollector getDynamicFilteringDataCollector(BatchExecNode<?> node)
public Transformation<RowData> createInputFormatTransformation(StreamExecutionEnvironment env, InputFormat<RowData,?> inputFormat, InternalTypeInfo<RowData> outputTypeInfo, String operatorName)
CommonExecTableSourceScan
Transformation
based on the given InputFormat
. The implementation
is different for streaming mode and batch mode.createInputFormatTransformation
in class CommonExecTableSourceScan
public BatchExecTableSourceScan copyAndRemoveInputs()
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.