Interface RankProcessStrategy
-
- All Known Implementing Classes:
RankProcessStrategy.AppendFastStrategy
,RankProcessStrategy.RetractStrategy
,RankProcessStrategy.UndefinedStrategy
,RankProcessStrategy.UpdateFastStrategy
public interface RankProcessStrategy
Base class of Strategy to choose different rank process function.
-
-
Nested Class Summary
Nested Classes Modifier and Type Interface Description static class
RankProcessStrategy.AppendFastStrategy
A strategy which only works when input only contains insertion changes.static class
RankProcessStrategy.RetractStrategy
A strategy which works when input contains update or deletion changes.static class
RankProcessStrategy.UndefinedStrategy
A placeholder strategy which will be inferred afterFlinkChangelogModeInferenceProgram
.static class
RankProcessStrategy.UpdateFastStrategy
A strategy which only works when input shouldn't contains deletion changes and input should have the givenRankProcessStrategy.UpdateFastStrategy.primaryKeys
and should be monotonic on the order by field.
-
Field Summary
Fields Modifier and Type Field Description static RankProcessStrategy.AppendFastStrategy
APPEND_FAST_STRATEGY
static RankProcessStrategy.RetractStrategy
RETRACT_STRATEGY
static RankProcessStrategy.UndefinedStrategy
UNDEFINED_STRATEGY
-
Method Summary
Static Methods Modifier and Type Method Description static List<RankProcessStrategy>
analyzeRankProcessStrategies(org.apache.flink.table.planner.plan.nodes.physical.stream.StreamPhysicalRel rank, org.apache.calcite.util.ImmutableBitSet partitionKey, org.apache.calcite.rel.RelCollation orderKey)
GetsRankProcessStrategy
based on input, partitionKey and orderKey.
-
-
-
Field Detail
-
UNDEFINED_STRATEGY
static final RankProcessStrategy.UndefinedStrategy UNDEFINED_STRATEGY
-
APPEND_FAST_STRATEGY
static final RankProcessStrategy.AppendFastStrategy APPEND_FAST_STRATEGY
-
RETRACT_STRATEGY
static final RankProcessStrategy.RetractStrategy RETRACT_STRATEGY
-
-
Method Detail
-
analyzeRankProcessStrategies
static List<RankProcessStrategy> analyzeRankProcessStrategies(org.apache.flink.table.planner.plan.nodes.physical.stream.StreamPhysicalRel rank, org.apache.calcite.util.ImmutableBitSet partitionKey, org.apache.calcite.rel.RelCollation orderKey)
GetsRankProcessStrategy
based on input, partitionKey and orderKey.
-
-