public class BatchExecSink extends CommonExecSink implements BatchExecNode<Object>
ExecNode
to to write data into an external sink defined by a DynamicTableSink
.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 |
---|
BatchExecSink(ReadableConfig tableConfig,
DynamicTableSinkSpec tableSinkSpec,
InputProperty inputProperty,
LogicalType outputType,
String description) |
Modifier and Type | Method and Description |
---|---|
protected RowType |
getPhysicalRowType(ResolvedSchema schema) |
protected int[] |
getPrimaryKeyIndices(RowType sinkRowType,
ResolvedSchema schema) |
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 BatchExecSink(ReadableConfig tableConfig, DynamicTableSinkSpec tableSinkSpec, InputProperty inputProperty, LogicalType outputType, 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
.protected RowType getPhysicalRowType(ResolvedSchema schema)
getPhysicalRowType
in class CommonExecSink
protected int[] getPrimaryKeyIndices(RowType sinkRowType, ResolvedSchema schema)
getPrimaryKeyIndices
in class CommonExecSink
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.