Class BatchExecExecutionOrderEnforcer
- java.lang.Object
-
- org.apache.flink.table.planner.plan.nodes.exec.ExecNodeBase<RowData>
-
- org.apache.flink.table.planner.plan.nodes.exec.batch.BatchExecExecutionOrderEnforcer
-
- All Implemented Interfaces:
BatchExecNode<RowData>
,ExecNode<RowData>
,ExecNodeTranslator<RowData>
,FusionCodegenExecNode
public class BatchExecExecutionOrderEnforcer extends ExecNodeBase<RowData> implements BatchExecNode<RowData>
BatchExecNode
for ExecutionOrderEnforcer.ExecutionOrderEnforcer has two inputs, one of which is a source, and the other is the dependent upstream. It enforces that the input source is executed after the dependent input is finished. Everything passed from the inputs is forwarded to the output, though typically the dependent input should not send anything.
The ExecutionOrderEnforcer should generally be chained with the source. If chaining is explicitly disabled, the enforcer can not work as expected.
The operator is used only for dynamic filtering at present.
-
-
Field Summary
-
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 BatchExecExecutionOrderEnforcer(ReadableConfig tableConfig, List<InputProperty> inputProperties, LogicalType outputType, String description)
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description boolean
supportFusionCodegen()
Whether this ExecNode supports OFCG or not.protected OpFusionCodegenSpecGenerator
translateToFusionCodegenSpecInternal(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config, org.apache.flink.table.planner.codegen.CodeGeneratorContext parentCtx)
Internal method, translates this node into a operator codegen spec generator.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, translateToFusionCodegenSpec, 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
translateToFusionCodegenSpec
-
-
-
-
Constructor Detail
-
BatchExecExecutionOrderEnforcer
public BatchExecExecutionOrderEnforcer(ReadableConfig tableConfig, List<InputProperty> inputProperties, LogicalType outputType, String description)
-
-
Method Detail
-
supportFusionCodegen
public boolean supportFusionCodegen()
Description copied from interface:FusionCodegenExecNode
Whether this ExecNode supports OFCG or not.- Specified by:
supportFusionCodegen
in interfaceFusionCodegenExecNode
- Overrides:
supportFusionCodegen
in classExecNodeBase<RowData>
-
translateToFusionCodegenSpecInternal
protected OpFusionCodegenSpecGenerator translateToFusionCodegenSpecInternal(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config, org.apache.flink.table.planner.codegen.CodeGeneratorContext parentCtx)
Description copied from class:ExecNodeBase
Internal method, translates this node into a operator codegen spec generator.- Overrides:
translateToFusionCodegenSpecInternal
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
.
-
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
.
-
-