Class StreamExecJoin
- java.lang.Object
-
- org.apache.flink.table.planner.plan.nodes.exec.ExecNodeBase<RowData>
-
- org.apache.flink.table.planner.plan.nodes.exec.stream.StreamExecJoin
-
- All Implemented Interfaces:
ExecNode<RowData>
,ExecNodeTranslator<RowData>
,FusionCodegenExecNode
,SingleTransformationTranslator<RowData>
,StreamExecNode<RowData>
@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.
-
-
Field Summary
Fields Modifier and Type Field 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
static String
LEFT_STATE_NAME
static String
RIGHT_STATE_NAME
-
Fields inherited from interface org.apache.flink.table.planner.plan.nodes.exec.ExecNode
FIELD_NAME_CONFIGURATION, FIELD_NAME_DESCRIPTION, FIELD_NAME_ID, FIELD_NAME_INPUT_PROPERTIES, FIELD_NAME_OUTPUT_TYPE, FIELD_NAME_STATE, FIELD_NAME_TYPE
-
-
Constructor Summary
Constructors Constructor Description StreamExecJoin(int id, ExecNodeContext context, ReadableConfig persistedConfig, JoinSpec joinSpec, List<int[]> leftUpsertKeys, List<int[]> rightUpsertKeys, List<StateMetadata> stateMetadataList, List<InputProperty> inputProperties, RowType outputType, String description)
StreamExecJoin(ReadableConfig tableConfig, JoinSpec joinSpec, List<int[]> leftUpsertKeys, List<int[]> rightUpsertKeys, InputProperty leftInputProperty, InputProperty rightInputProperty, Map<Integer,Long> stateTtlFromHint, RowType outputType, String description)
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description protected Transformation<RowData>
translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config)
Internal method, translates this node into a Flink operator.-
Methods inherited from class org.apache.flink.table.planner.plan.nodes.exec.ExecNodeBase
accept, createFormattedTransformationDescription, createFormattedTransformationName, createTransformationDescription, createTransformationMeta, createTransformationMeta, createTransformationName, createTransformationUid, getContextFromAnnotation, getDescription, getId, getInputEdges, getInputProperties, getOutputType, getPersistedConfig, getSimplifiedName, getTransformation, inputsContainSingleton, replaceInputEdge, setCompiled, setInputEdges, supportFusionCodegen, translateToFusionCodegenSpec, translateToFusionCodegenSpecInternal, translateToPlan
-
Methods inherited from class java.lang.Object
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
-
Methods inherited from interface org.apache.flink.table.planner.plan.nodes.exec.ExecNode
accept, getDescription, getId, getInputEdges, getInputProperties, getOutputType, replaceInputEdge, setCompiled, setInputEdges
-
Methods inherited from interface org.apache.flink.table.planner.plan.nodes.exec.ExecNodeTranslator
translateToPlan
-
Methods inherited from interface org.apache.flink.table.planner.plan.nodes.exec.FusionCodegenExecNode
supportFusionCodegen, translateToFusionCodegenSpec
-
-
-
-
Field Detail
-
JOIN_TRANSFORMATION
public static final String JOIN_TRANSFORMATION
- See Also:
- Constant Field Values
-
LEFT_STATE_NAME
public static final String LEFT_STATE_NAME
- See Also:
- Constant Field Values
-
RIGHT_STATE_NAME
public static final String RIGHT_STATE_NAME
- See Also:
- Constant Field Values
-
FIELD_NAME_JOIN_SPEC
public static final String FIELD_NAME_JOIN_SPEC
- See Also:
- Constant Field Values
-
FIELD_NAME_LEFT_UPSERT_KEYS
public static final String FIELD_NAME_LEFT_UPSERT_KEYS
- See Also:
- Constant Field Values
-
FIELD_NAME_RIGHT_UPSERT_KEYS
public static final String FIELD_NAME_RIGHT_UPSERT_KEYS
- See Also:
- Constant Field Values
-
-
Constructor Detail
-
StreamExecJoin
public StreamExecJoin(ReadableConfig tableConfig, JoinSpec joinSpec, List<int[]> leftUpsertKeys, List<int[]> rightUpsertKeys, InputProperty leftInputProperty, InputProperty rightInputProperty, Map<Integer,Long> stateTtlFromHint, RowType outputType, String description)
-
StreamExecJoin
public StreamExecJoin(int id, ExecNodeContext context, ReadableConfig persistedConfig, JoinSpec joinSpec, List<int[]> leftUpsertKeys, List<int[]> rightUpsertKeys, @Nullable List<StateMetadata> stateMetadataList, List<InputProperty> inputProperties, RowType outputType, String description)
-
-
Method Detail
-
translateToPlanInternal
protected Transformation<RowData> translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config)
Description copied from class:ExecNodeBase
Internal method, translates this node into a Flink operator.- Specified by:
translateToPlanInternal
in classExecNodeBase<RowData>
- Parameters:
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 theplanner
. For more details checkExecNodeConfig
.
-
-