public abstract class CommonPhysicalMatchRule
extends org.apache.calcite.rel.convert.ConverterRule
FlinkLogicalMatch
to physical Match rel.org.apache.calcite.rel.convert.ConverterRule.Config
org.apache.calcite.plan.RelRule.Done, org.apache.calcite.plan.RelRule.MatchHandler<R extends org.apache.calcite.plan.RelOptRule>, org.apache.calcite.plan.RelRule.OperandBuilder, org.apache.calcite.plan.RelRule.OperandDetailBuilder<R extends org.apache.calcite.rel.RelNode>, org.apache.calcite.plan.RelRule.OperandTransform
Constructor and Description |
---|
CommonPhysicalMatchRule(Class<? extends org.apache.calcite.rel.RelNode> clazz,
org.apache.calcite.plan.RelTrait in,
org.apache.calcite.plan.RelTrait out,
String descriptionPrefix) |
Modifier and Type | Method and Description |
---|---|
org.apache.calcite.rel.RelNode |
convert(org.apache.calcite.rel.RelNode rel,
org.apache.flink.table.planner.plan.nodes.FlinkConvention convention) |
protected abstract org.apache.calcite.rel.RelNode |
convertToPhysicalMatch(org.apache.calcite.plan.RelOptCluster cluster,
org.apache.calcite.plan.RelTraitSet traitSet,
org.apache.calcite.rel.RelNode convertInput,
org.apache.flink.table.planner.plan.logical.MatchRecognize matchRecognize,
org.apache.calcite.rel.type.RelDataType rowType) |
boolean |
matches(org.apache.calcite.plan.RelOptRuleCall call) |
convert, getInTrait, getOutConvention, getOutTrait, getTraitDef, isGuaranteed, onMatch
public boolean matches(org.apache.calcite.plan.RelOptRuleCall call)
matches
in class org.apache.calcite.plan.RelOptRule
public org.apache.calcite.rel.RelNode convert(org.apache.calcite.rel.RelNode rel, org.apache.flink.table.planner.plan.nodes.FlinkConvention convention)
protected abstract org.apache.calcite.rel.RelNode convertToPhysicalMatch(org.apache.calcite.plan.RelOptCluster cluster, org.apache.calcite.plan.RelTraitSet traitSet, org.apache.calcite.rel.RelNode convertInput, org.apache.flink.table.planner.plan.logical.MatchRecognize matchRecognize, org.apache.calcite.rel.type.RelDataType rowType)
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.