public abstract class CommonExecSink extends ExecNodeBase<Object> implements MultipleTransformationTranslator<Object>
ExecNode
to write data to an external sink defined by a DynamicTableSink
.Modifier and Type | Field and Description |
---|---|
static String |
CONSTRAINT_VALIDATOR_TRANSFORMATION |
static String |
FIELD_NAME_DYNAMIC_TABLE_SINK |
static String |
PARTITIONER_TRANSFORMATION |
static String |
ROW_KIND_SETTER |
static String |
SINK_TRANSFORMATION |
protected boolean |
sinkParallelismConfigured |
protected DynamicTableSinkSpec |
tableSinkSpec |
static String |
TIMESTAMP_INSERTER_TRANSFORMATION |
static String |
UPSERT_MATERIALIZE_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 |
CommonExecSink(int id,
ExecNodeContext context,
ReadableConfig persistedConfig,
DynamicTableSinkSpec tableSinkSpec,
ChangelogMode inputChangelogMode,
boolean isBounded,
List<InputProperty> inputProperties,
LogicalType outputType,
String description) |
Modifier and Type | Method and Description |
---|---|
protected abstract Transformation<RowData> |
applyUpsertMaterialize(Transformation<RowData> inputTransform,
int[] primaryKeys,
int sinkParallelism,
ExecNodeConfig config,
ClassLoader classLoader,
RowType physicalRowType,
int[] inputUpsertKey) |
protected Transformation<Object> |
createSinkTransformation(StreamExecutionEnvironment streamExecEnv,
ExecNodeConfig config,
ClassLoader classLoader,
Transformation<RowData> inputTransform,
DynamicTableSink tableSink,
int rowtimeFieldIndex,
boolean upsertMaterialize,
int[] inputUpsertKey) |
protected RowType |
getPhysicalRowType(ResolvedSchema schema) |
protected int[] |
getPrimaryKeyIndices(RowType sinkRowType,
ResolvedSchema schema) |
String |
getSimplifiedName() |
DynamicTableSinkSpec |
getTableSinkSpec() |
accept, createFormattedTransformationDescription, createFormattedTransformationName, createTransformationDescription, createTransformationMeta, createTransformationMeta, createTransformationName, createTransformationUid, getContextFromAnnotation, getDescription, getId, getInputEdges, getInputProperties, getOutputType, getPersistedConfig, getTransformation, inputsContainSingleton, replaceInputEdge, setCompiled, setInputEdges, supportFusionCodegen, translateToFusionCodegenSpec, translateToFusionCodegenSpecInternal, translateToPlan, translateToPlanInternal
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
translateToPlan
public static final String CONSTRAINT_VALIDATOR_TRANSFORMATION
public static final String PARTITIONER_TRANSFORMATION
public static final String UPSERT_MATERIALIZE_TRANSFORMATION
public static final String TIMESTAMP_INSERTER_TRANSFORMATION
public static final String ROW_KIND_SETTER
public static final String SINK_TRANSFORMATION
public static final String FIELD_NAME_DYNAMIC_TABLE_SINK
protected final DynamicTableSinkSpec tableSinkSpec
protected boolean sinkParallelismConfigured
protected CommonExecSink(int id, ExecNodeContext context, ReadableConfig persistedConfig, DynamicTableSinkSpec tableSinkSpec, ChangelogMode inputChangelogMode, boolean isBounded, List<InputProperty> inputProperties, LogicalType outputType, String description)
public String getSimplifiedName()
getSimplifiedName
in class ExecNodeBase<Object>
public DynamicTableSinkSpec getTableSinkSpec()
protected Transformation<Object> createSinkTransformation(StreamExecutionEnvironment streamExecEnv, ExecNodeConfig config, ClassLoader classLoader, Transformation<RowData> inputTransform, DynamicTableSink tableSink, int rowtimeFieldIndex, boolean upsertMaterialize, int[] inputUpsertKey)
protected abstract Transformation<RowData> applyUpsertMaterialize(Transformation<RowData> inputTransform, int[] primaryKeys, int sinkParallelism, ExecNodeConfig config, ClassLoader classLoader, RowType physicalRowType, int[] inputUpsertKey)
protected int[] getPrimaryKeyIndices(RowType sinkRowType, ResolvedSchema schema)
protected RowType getPhysicalRowType(ResolvedSchema schema)
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.