public interface RankProcessStrategy
Modifier and Type | Interface and 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 after
FlinkChangelogModeInferenceProgram . |
static class |
RankProcessStrategy.UpdateFastStrategy
A strategy which only works when input shouldn't contains deletion changes and input should
have the given
RankProcessStrategy.UpdateFastStrategy.primaryKeys and should be monotonic on the order by field. |
Modifier and Type | Field and Description |
---|---|
static RankProcessStrategy.AppendFastStrategy |
APPEND_FAST_STRATEGY |
static RankProcessStrategy.RetractStrategy |
RETRACT_STRATEGY |
static RankProcessStrategy.UndefinedStrategy |
UNDEFINED_STRATEGY |
Modifier and Type | Method and 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)
Gets
RankProcessStrategy based on input, partitionKey and orderKey. |
static final RankProcessStrategy.UndefinedStrategy UNDEFINED_STRATEGY
static final RankProcessStrategy.AppendFastStrategy APPEND_FAST_STRATEGY
static final RankProcessStrategy.RetractStrategy RETRACT_STRATEGY
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)
RankProcessStrategy
based on input, partitionKey and orderKey.Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.