Class BatchExecTableSourceScan
- java.lang.Object
-
- org.apache.flink.table.planner.plan.nodes.exec.ExecNodeBase<RowData>
-
- org.apache.flink.table.planner.plan.nodes.exec.common.CommonExecTableSourceScan
-
- org.apache.flink.table.planner.plan.nodes.exec.batch.BatchExecTableSourceScan
-
- All Implemented Interfaces:
BatchExecNode<RowData>
,ExecNode<RowData>
,ExecNodeTranslator<RowData>
,FusionCodegenExecNode
,MultipleTransformationTranslator<RowData>
@ExecNodeMetadata(name="batch-exec-table-source-scan", version=1, producedTransformations="source", minPlanVersion=v2_0, minStateVersion=v2_0) public class BatchExecTableSourceScan extends CommonExecTableSourceScan implements BatchExecNode<RowData>
BatchExecNode
to read data from an external source defined by a boundedScanTableSource
.
-
-
Field Summary
-
Fields inherited from class org.apache.flink.table.planner.plan.nodes.exec.common.CommonExecTableSourceScan
FIELD_NAME_SCAN_TABLE_SOURCE, SOURCE_TRANSFORMATION
-
Fields inherited from interface org.apache.flink.table.planner.plan.nodes.exec.ExecNode
FIELD_NAME_CONFIGURATION, FIELD_NAME_DESCRIPTION, FIELD_NAME_ID, FIELD_NAME_INPUT_PROPERTIES, FIELD_NAME_OUTPUT_TYPE, FIELD_NAME_STATE, FIELD_NAME_TYPE
-
-
Constructor Summary
Constructors Constructor Description BatchExecTableSourceScan(int id, ExecNodeContext context, ReadableConfig tableConfig, DynamicTableSourceSpec tableSourceSpec, RowType outputType, String description)
BatchExecTableSourceScan(ReadableConfig tableConfig, DynamicTableSourceSpec tableSourceSpec, InputProperty inputProperty, RowType outputType, String description)
BatchExecTableSourceScan(ReadableConfig tableConfig, DynamicTableSourceSpec tableSourceSpec, RowType outputType, String description)
-
Method Summary
All Methods Static Methods Instance Methods Concrete Methods Modifier and Type Method Description BatchExecTableSourceScan
copyAndRemoveInputs()
Transformation<RowData>
createInputFormatTransformation(StreamExecutionEnvironment env, InputFormat<RowData,?> inputFormat, InternalTypeInfo<RowData> outputTypeInfo, String operatorName)
Creates aTransformation
based on the givenInputFormat
.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.-
Methods inherited from class org.apache.flink.table.planner.plan.nodes.exec.common.CommonExecTableSourceScan
createSourceFunctionTransformation, getPhysicalRowType, getPrimaryKeyIndices, getSimplifiedName, getTableSourceSpec
-
Methods inherited from class org.apache.flink.table.planner.plan.nodes.exec.ExecNodeBase
accept, createFormattedTransformationDescription, createFormattedTransformationName, createTransformationDescription, createTransformationMeta, createTransformationMeta, createTransformationName, createTransformationUid, getContextFromAnnotation, getDescription, getId, getInputEdges, getInputProperties, getOutputType, getPersistedConfig, getTransformation, inputsContainSingleton, replaceInputEdge, setCompiled, setInputEdges, supportFusionCodegen, translateToFusionCodegenSpec, translateToFusionCodegenSpecInternal, translateToPlan
-
Methods inherited from class java.lang.Object
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
-
Methods inherited from interface org.apache.flink.table.planner.plan.nodes.exec.ExecNode
accept, getDescription, getId, getInputEdges, getInputProperties, getOutputType, replaceInputEdge, setCompiled, setInputEdges
-
Methods inherited from interface org.apache.flink.table.planner.plan.nodes.exec.ExecNodeTranslator
translateToPlan
-
Methods inherited from interface org.apache.flink.table.planner.plan.nodes.exec.FusionCodegenExecNode
supportFusionCodegen, translateToFusionCodegenSpec
-
-
-
-
Constructor Detail
-
BatchExecTableSourceScan
public BatchExecTableSourceScan(ReadableConfig tableConfig, DynamicTableSourceSpec tableSourceSpec, InputProperty inputProperty, RowType outputType, String description)
-
BatchExecTableSourceScan
public BatchExecTableSourceScan(ReadableConfig tableConfig, DynamicTableSourceSpec tableSourceSpec, RowType outputType, String description)
-
BatchExecTableSourceScan
public BatchExecTableSourceScan(int id, ExecNodeContext context, ReadableConfig tableConfig, DynamicTableSourceSpec tableSourceSpec, RowType outputType, String description)
-
-
Method Detail
-
getDynamicFilteringDataListenerID
public String getDynamicFilteringDataListenerID()
-
translateToPlanInternal
protected Transformation<RowData> translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config)
Description copied from class:ExecNodeBase
Internal method, translates this node into a Flink operator.- Overrides:
translateToPlanInternal
in classCommonExecTableSourceScan
- Parameters:
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 theplanner
. For more details checkExecNodeConfig
.
-
getDynamicFilteringDataCollector
public static BatchExecDynamicFilteringDataCollector getDynamicFilteringDataCollector(BatchExecNode<?> node)
-
createInputFormatTransformation
public Transformation<RowData> createInputFormatTransformation(StreamExecutionEnvironment env, InputFormat<RowData,?> inputFormat, InternalTypeInfo<RowData> outputTypeInfo, String operatorName)
Description copied from class:CommonExecTableSourceScan
Creates aTransformation
based on the givenInputFormat
. The implementation is different for streaming mode and batch mode.- Specified by:
createInputFormatTransformation
in classCommonExecTableSourceScan
-
copyAndRemoveInputs
public BatchExecTableSourceScan copyAndRemoveInputs()
-
-