@ExecNodeMetadata(name="stream-exec-join", version=1, producedTransformations="join", minPlanVersion=v1_15, minStateVersion=v1_15) public class StreamExecJoin extends ExecNodeBase<RowData> implements StreamExecNode<RowData>, SingleTransformationTranslator<RowData>
StreamExecNode
for regular Joins.
Regular joins are the most generic type of join in which any new records or changes to either side of the join input are visible and are affecting the whole join result.
Modifier and Type | Field and Description |
---|---|
static String |
FIELD_NAME_JOIN_SPEC |
static String |
FIELD_NAME_LEFT_UPSERT_KEYS |
static String |
FIELD_NAME_RIGHT_UPSERT_KEYS |
static String |
JOIN_TRANSFORMATION |
FIELD_NAME_CONFIGURATION, FIELD_NAME_DESCRIPTION, FIELD_NAME_ID, FIELD_NAME_INPUT_PROPERTIES, FIELD_NAME_OUTPUT_TYPE, FIELD_NAME_TYPE
Constructor and Description |
---|
StreamExecJoin(int id,
ExecNodeContext context,
ReadableConfig persistedConfig,
JoinSpec joinSpec,
List<int[]> leftUpsertKeys,
List<int[]> rightUpsertKeys,
List<InputProperty> inputProperties,
RowType outputType,
String description) |
StreamExecJoin(ReadableConfig tableConfig,
JoinSpec joinSpec,
List<int[]> leftUpsertKeys,
List<int[]> rightUpsertKeys,
InputProperty leftInputProperty,
InputProperty rightInputProperty,
RowType outputType,
String description) |
Modifier and Type | Method and Description |
---|---|
protected Transformation<RowData> |
translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config)
Internal method, translates this node into a Flink operator.
|
accept, createFormattedTransformationDescription, createFormattedTransformationName, createTransformationDescription, createTransformationMeta, createTransformationMeta, createTransformationName, createTransformationUid, getContextFromAnnotation, getDescription, getId, getInputEdges, getInputProperties, getOutputType, getPersistedConfig, getSimplifiedName, 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 JOIN_TRANSFORMATION
public static final String FIELD_NAME_JOIN_SPEC
public static final String FIELD_NAME_LEFT_UPSERT_KEYS
public static final String FIELD_NAME_RIGHT_UPSERT_KEYS
public StreamExecJoin(ReadableConfig tableConfig, JoinSpec joinSpec, List<int[]> leftUpsertKeys, List<int[]> rightUpsertKeys, InputProperty leftInputProperty, InputProperty rightInputProperty, RowType outputType, String description)
public StreamExecJoin(int id, ExecNodeContext context, ReadableConfig persistedConfig, JoinSpec joinSpec, List<int[]> leftUpsertKeys, List<int[]> rightUpsertKeys, List<InputProperty> inputProperties, RowType outputType, String description)
protected Transformation<RowData> translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config)
ExecNodeBase
translateToPlanInternal
in class ExecNodeBase<RowData>
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–2024 The Apache Software Foundation. All rights reserved.