Class CommonExecLegacySink<T>
- java.lang.Object
-
- org.apache.flink.table.planner.plan.nodes.exec.ExecNodeBase<T>
-
- org.apache.flink.table.planner.plan.nodes.exec.common.CommonExecLegacySink<T>
-
- Type Parameters:
T
- The return type of theTableSink
.
- All Implemented Interfaces:
ExecNode<T>
,ExecNodeTranslator<T>
,FusionCodegenExecNode
,MultipleTransformationTranslator<T>
- Direct Known Subclasses:
BatchExecLegacySink
,StreamExecLegacySink
public abstract class CommonExecLegacySink<T> extends ExecNodeBase<T> implements MultipleTransformationTranslator<T>
-
-
Field Summary
Fields Modifier and Type Field Description protected boolean
isStreaming
protected boolean
needRetraction
protected TableSink<T>
tableSink
protected String[]
upsertKeys
-
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 CommonExecLegacySink(int id, ExecNodeContext context, ReadableConfig persistedConfig, TableSink<T> tableSink, String[] upsertKeys, boolean needRetraction, boolean isStreaming, InputProperty inputProperty, LogicalType outputType, String description)
-
Method Summary
All Methods Instance Methods Abstract Methods Concrete Methods Modifier and Type Method Description protected abstract RowType
checkAndConvertInputTypeIfNeeded(RowType inputRowType)
Check whether the given row type is legal and do some conversion if needed.protected Transformation<T>
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.ExecNodeBase
accept, createFormattedTransformationDescription, createFormattedTransformationName, createTransformationDescription, createTransformationMeta, createTransformationMeta, createTransformationName, createTransformationUid, getContextFromAnnotation, getDescription, getId, getInputEdges, getInputProperties, getOutputType, getPersistedConfig, getSimplifiedName, 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.ExecNodeTranslator
translateToPlan
-
-
-
-
Constructor Detail
-
CommonExecLegacySink
public CommonExecLegacySink(int id, ExecNodeContext context, ReadableConfig persistedConfig, TableSink<T> tableSink, @Nullable String[] upsertKeys, boolean needRetraction, boolean isStreaming, InputProperty inputProperty, LogicalType outputType, String description)
-
-
Method Detail
-
translateToPlanInternal
protected Transformation<T> 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.- Specified by:
translateToPlanInternal
in classExecNodeBase<T>
- 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
.
-
-