public class BatchExecHashJoin extends ExecNodeBase<RowData> implements BatchExecNode<RowData>, SingleTransformationTranslator<RowData>
BatchExecNode
for Hash Join.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 |
---|
BatchExecHashJoin(ReadableConfig tableConfig,
JoinSpec joinSpec,
int estimatedLeftAvgRowSize,
int estimatedRightAvgRowSize,
long estimatedLeftRowCount,
long estimatedRightRowCount,
boolean isBroadcast,
boolean leftIsBuild,
boolean tryDistinctBuildRow,
InputProperty leftInputProperty,
InputProperty rightInputProperty,
RowType outputType,
String description) |
Modifier and Type | Method and 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.
|
accept, createFormattedTransformationDescription, createFormattedTransformationName, createTransformationDescription, createTransformationMeta, createTransformationMeta, createTransformationName, createTransformationUid, getContextFromAnnotation, getDescription, getId, getInputEdges, getInputProperties, getOutputType, getPersistedConfig, getSimplifiedName, getTransformation, inputsContainSingleton, replaceInputEdge, setCompiled, setInputEdges, translateToFusionCodegenSpec, translateToPlan
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
accept, getDescription, getId, getInputEdges, getInputProperties, getOutputType, replaceInputEdge, setCompiled, setInputEdges
translateToPlan
translateToFusionCodegenSpec
public BatchExecHashJoin(ReadableConfig tableConfig, JoinSpec joinSpec, int estimatedLeftAvgRowSize, int estimatedRightAvgRowSize, long estimatedLeftRowCount, long estimatedRightRowCount, boolean isBroadcast, boolean leftIsBuild, boolean tryDistinctBuildRow, InputProperty leftInputProperty, InputProperty rightInputProperty, 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
.public boolean supportFusionCodegen()
FusionCodegenExecNode
supportFusionCodegen
in interface FusionCodegenExecNode
supportFusionCodegen
in class ExecNodeBase<RowData>
protected OpFusionCodegenSpecGenerator translateToFusionCodegenSpecInternal(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config, org.apache.flink.table.planner.codegen.CodeGeneratorContext parentCtx)
ExecNodeBase
translateToFusionCodegenSpecInternal
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.