public abstract class CommonExecMatch extends ExecNodeBase<RowData> implements ExecNode<RowData>, MultipleTransformationTranslator<RowData>
ExecNode
which matches along with MATCH_RECOGNIZE.Modifier and Type | Field and Description |
---|---|
static String |
MATCH_TRANSFORMATION |
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 |
---|
CommonExecMatch(int id,
ExecNodeContext context,
ReadableConfig persistedConfig,
MatchSpec matchSpec,
List<InputProperty> inputProperties,
LogicalType outputType,
String description) |
Modifier and Type | Method and Description |
---|---|
protected void |
checkOrderKeys(RowType inputRowType) |
abstract boolean |
isProcTime(RowType inputRowType) |
protected Transformation<RowData> |
translateOrder(Transformation<RowData> inputTransform,
RowType inputRowType,
ExecNodeConfig config) |
static Tuple2<Pattern<RowData,RowData>,List<String>> |
translatePattern(MatchSpec matchSpec,
ReadableConfig config,
ClassLoader classLoader,
RelBuilder relBuilder,
RowType inputRowType) |
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, supportFusionCodegen, translateToFusionCodegenSpec, translateToFusionCodegenSpecInternal, translateToPlan
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
accept, getDescription, getId, getInputEdges, getInputProperties, getOutputType, replaceInputEdge, setCompiled, setInputEdges
supportFusionCodegen, translateToFusionCodegenSpec
translateToPlan
public static final String MATCH_TRANSFORMATION
public CommonExecMatch(int id, ExecNodeContext context, ReadableConfig persistedConfig, MatchSpec matchSpec, List<InputProperty> inputProperties, LogicalType 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
.protected void checkOrderKeys(RowType inputRowType)
protected Transformation<RowData> translateOrder(Transformation<RowData> inputTransform, RowType inputRowType, ExecNodeConfig config)
@VisibleForTesting public static Tuple2<Pattern<RowData,RowData>,List<String>> translatePattern(MatchSpec matchSpec, ReadableConfig config, ClassLoader classLoader, RelBuilder relBuilder, RowType inputRowType)
public abstract boolean isProcTime(RowType inputRowType)
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.