T
- The return type of the TableSink
.public abstract class CommonExecLegacySink<T> extends ExecNodeBase<T> implements MultipleTransformationTranslator<T>
Modifier and Type | Field and Description |
---|---|
protected boolean |
isStreaming |
protected boolean |
needRetraction |
protected TableSink<T> |
tableSink |
protected String[] |
upsertKeys |
FIELD_NAME_DESCRIPTION, FIELD_NAME_ID, FIELD_NAME_INPUT_PROPERTIES, FIELD_NAME_OUTPUT_TYPE
Constructor and Description |
---|
CommonExecLegacySink(TableSink<T> tableSink,
String[] upsertKeys,
boolean needRetraction,
boolean isStreaming,
InputProperty inputProperty,
LogicalType outputType,
String description) |
Modifier and Type | Method and 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)
Internal method, translates this node into a Flink operator.
|
accept, getDescription, getId, getInputEdges, getInputProperties, getNewNodeId, getOutputType, inputsContainSingleton, replaceInputEdge, resetIdCounter, setInputEdges, translateToPlan
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
translateToPlan
protected final boolean needRetraction
protected final boolean isStreaming
public CommonExecLegacySink(TableSink<T> tableSink, @Nullable String[] upsertKeys, boolean needRetraction, boolean isStreaming, InputProperty inputProperty, LogicalType outputType, String description)
protected Transformation<T> translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner)
ExecNodeBase
translateToPlanInternal
in class ExecNodeBase<T>
Copyright © 2014–2023 The Apache Software Foundation. All rights reserved.