public abstract class CommonExecTableSourceScan extends ExecNodeBase<RowData> implements MultipleTransformationTranslator<RowData>
ExecNode
to read data from an external source defined by a ScanTableSource
.Modifier and Type | Field and Description |
---|---|
static String |
FIELD_NAME_SCAN_TABLE_SOURCE |
static String |
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
Modifier | Constructor and Description |
---|---|
protected |
CommonExecTableSourceScan(int id,
ExecNodeContext context,
ReadableConfig persistedConfig,
DynamicTableSourceSpec tableSourceSpec,
List<InputProperty> inputProperties,
LogicalType outputType,
String description) |
Modifier and Type | Method and Description |
---|---|
protected abstract Transformation<RowData> |
createInputFormatTransformation(StreamExecutionEnvironment env,
InputFormat<RowData,?> inputFormat,
InternalTypeInfo<RowData> outputTypeInfo,
String operatorName)
Creates a
Transformation based on the given InputFormat . |
protected Transformation<RowData> |
createSourceFunctionTransformation(StreamExecutionEnvironment env,
SourceFunction<RowData> function,
boolean isBounded,
String operatorName,
TypeInformation<RowData> outputTypeInfo,
int sourceParallelism,
boolean sourceParallelismConfigured)
Deprecated.
This method relies on the
SourceFunction API, which is due to be
removed. |
protected RowType |
getPhysicalRowType(ResolvedSchema schema) |
protected int[] |
getPrimaryKeyIndices(RowType sourceRowType,
ResolvedSchema schema) |
String |
getSimplifiedName() |
DynamicTableSourceSpec |
getTableSourceSpec() |
protected Transformation<RowData> |
translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config)
Internal method, translates this node into a Flink operator.
|
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
translateToPlan
public static final String SOURCE_TRANSFORMATION
public static final String FIELD_NAME_SCAN_TABLE_SOURCE
protected CommonExecTableSourceScan(int id, ExecNodeContext context, ReadableConfig persistedConfig, DynamicTableSourceSpec tableSourceSpec, List<InputProperty> inputProperties, LogicalType outputType, String description)
public String getSimplifiedName()
getSimplifiedName
in class ExecNodeBase<RowData>
public DynamicTableSourceSpec getTableSourceSpec()
protected Transformation<RowData> translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config)
ExecNodeBase
translateToPlanInternal
in class ExecNodeBase<RowData>
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 RowType getPhysicalRowType(ResolvedSchema schema)
protected int[] getPrimaryKeyIndices(RowType sourceRowType, ResolvedSchema schema)
@Deprecated protected Transformation<RowData> createSourceFunctionTransformation(StreamExecutionEnvironment env, SourceFunction<RowData> function, boolean isBounded, String operatorName, TypeInformation<RowData> outputTypeInfo, int sourceParallelism, boolean sourceParallelismConfigured)
SourceFunction
API, which is due to be
removed.StreamExecutionEnvironment.addSource(SourceFunction, String,
TypeInformation)
but with custom Boundedness
.protected abstract Transformation<RowData> createInputFormatTransformation(StreamExecutionEnvironment env, InputFormat<RowData,?> inputFormat, InternalTypeInfo<RowData> outputTypeInfo, String operatorName)
Transformation
based on the given InputFormat
. The implementation
is different for streaming mode and batch mode.Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.