public class BatchExecExchange extends CommonExecExchange implements BatchExecNode<RowData>
ExecNode
represents a change of partitioning of the input elements for batch.
TODO Remove this class once FLINK-21224 is finished.
FIELD_NAME_CONFIGURATION, FIELD_NAME_DESCRIPTION, FIELD_NAME_ID, FIELD_NAME_INPUT_PROPERTIES, FIELD_NAME_OUTPUT_TYPE, FIELD_NAME_STATE, FIELD_NAME_TYPE
Constructor and Description |
---|
BatchExecExchange(ReadableConfig tableConfig,
InputProperty inputProperty,
RowType outputType,
String description) |
Modifier and Type | Method and Description |
---|---|
String |
getDescription()
Returns a string which describes this node.
|
Optional<StreamExchangeMode> |
getRequiredExchangeMode() |
void |
setRequiredExchangeMode(StreamExchangeMode requiredExchangeMode) |
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, getId, getInputEdges, getInputProperties, getOutputType, getPersistedConfig, getSimplifiedName, getTransformation, inputsContainSingleton, replaceInputEdge, setCompiled, setInputEdges, supportFusionCodegen, translateToFusionCodegenSpec, translateToFusionCodegenSpecInternal, translateToPlan
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
accept, getId, getInputEdges, getInputProperties, getOutputType, replaceInputEdge, setCompiled, setInputEdges
translateToPlan
supportFusionCodegen, translateToFusionCodegenSpec
public BatchExecExchange(ReadableConfig tableConfig, InputProperty inputProperty, RowType outputType, String description)
public void setRequiredExchangeMode(@Nullable StreamExchangeMode requiredExchangeMode)
public String getDescription()
ExecNode
getDescription
in interface ExecNode<RowData>
getDescription
in class ExecNodeBase<RowData>
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
.@VisibleForTesting public Optional<StreamExchangeMode> getRequiredExchangeMode()
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.