@ExecNodeMetadata(name="stream-exec-sink", version=1, consumedOptions={"table.exec.sink.not-null-enforcer","table.exec.sink.type-length-enforcer","table.exec.sink.upsert-materialize","table.exec.sink.keyed-shuffle"}, producedTransformations={"constraint-validator","partitioner","upsert-materialize","timestamp-inserter","sink"}, minPlanVersion=v1_15, minStateVersion=v1_15) public class StreamExecSink extends CommonExecSink implements StreamExecNode<Object>
ExecNode
to to write data into an external sink defined by a DynamicTableSink
.Modifier and Type | Field and Description |
---|---|
static String |
FIELD_NAME_INPUT_CHANGELOG_MODE |
static String |
FIELD_NAME_INPUT_UPSERT_KEY |
static String |
FIELD_NAME_REQUIRE_UPSERT_MATERIALIZE |
CONSTRAINT_VALIDATOR_TRANSFORMATION, FIELD_NAME_DYNAMIC_TABLE_SINK, PARTITIONER_TRANSFORMATION, ROW_KIND_SETTER, SINK_TRANSFORMATION, tableSinkSpec, TIMESTAMP_INSERTER_TRANSFORMATION, UPSERT_MATERIALIZE_TRANSFORMATION
FIELD_NAME_CONFIGURATION, FIELD_NAME_DESCRIPTION, FIELD_NAME_ID, FIELD_NAME_INPUT_PROPERTIES, FIELD_NAME_OUTPUT_TYPE, FIELD_NAME_TYPE
Constructor and Description |
---|
StreamExecSink(int id,
ExecNodeContext context,
ReadableConfig persistedConfig,
DynamicTableSinkSpec tableSinkSpec,
ChangelogMode inputChangelogMode,
List<InputProperty> inputProperties,
LogicalType outputType,
boolean upsertMaterialize,
int[] inputUpsertKey,
String description) |
StreamExecSink(ReadableConfig tableConfig,
DynamicTableSinkSpec tableSinkSpec,
ChangelogMode inputChangelogMode,
InputProperty inputProperty,
LogicalType outputType,
boolean upsertMaterialize,
int[] inputUpsertKey,
String description) |
Modifier and Type | Method and Description |
---|---|
protected Transformation<Object> |
translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config)
Internal method, translates this node into a Flink operator.
|
createSinkTransformation, getSimplifiedName, getTableSinkSpec
accept, createFormattedTransformationDescription, createFormattedTransformationName, createTransformationDescription, createTransformationMeta, createTransformationMeta, createTransformationName, createTransformationUid, getContextFromAnnotation, getDescription, getId, getInputEdges, getInputProperties, getOutputType, getPersistedConfig, getTransformation, inputsContainSingleton, replaceInputEdge, resetTransformation, setCompiled, setInputEdges, translateToPlan
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
accept, getDescription, getId, getInputEdges, getInputProperties, getOutputType, replaceInputEdge, setCompiled, setInputEdges
translateToPlan
public static final String FIELD_NAME_INPUT_CHANGELOG_MODE
public static final String FIELD_NAME_REQUIRE_UPSERT_MATERIALIZE
public static final String FIELD_NAME_INPUT_UPSERT_KEY
public StreamExecSink(ReadableConfig tableConfig, DynamicTableSinkSpec tableSinkSpec, ChangelogMode inputChangelogMode, InputProperty inputProperty, LogicalType outputType, boolean upsertMaterialize, int[] inputUpsertKey, String description)
public StreamExecSink(int id, ExecNodeContext context, ReadableConfig persistedConfig, DynamicTableSinkSpec tableSinkSpec, ChangelogMode inputChangelogMode, List<InputProperty> inputProperties, LogicalType outputType, boolean upsertMaterialize, int[] inputUpsertKey, String description)
protected Transformation<Object> translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config)
ExecNodeBase
translateToPlanInternal
in class ExecNodeBase<Object>
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
.Copyright © 2014–2023 The Apache Software Foundation. All rights reserved.