@ExecNodeMetadata(name="stream-exec-rank", version=1, consumedOptions="table.exec.rank.topn-cache-size", producedTransformations="rank", minPlanVersion=v1_15, minStateVersion=v1_15) public class StreamExecRank extends ExecNodeBase<RowData> implements StreamExecNode<RowData>, SingleTransformationTranslator<RowData>
ExecNode
for Rank.Modifier and Type | Field and Description |
---|---|
static String |
FIELD_NAME_GENERATE_UPDATE_BEFORE |
static String |
FIELD_NAME_OUTPUT_RANK_NUMBER |
static String |
FIELD_NAME_PARTITION_SPEC |
static String |
FIELD_NAME_RANK_RANG |
static String |
FIELD_NAME_RANK_STRATEGY |
static String |
FIELD_NAME_RANK_TYPE |
static String |
FIELD_NAME_SORT_SPEC |
static String |
RANK_TRANSFORMATION |
static String |
STATE_NAME |
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 |
---|
StreamExecRank(int id,
ExecNodeContext context,
ReadableConfig persistedConfig,
RankType rankType,
PartitionSpec partitionSpec,
SortSpec sortSpec,
RankRange rankRange,
RankProcessStrategy rankStrategy,
boolean outputRankNumber,
boolean generateUpdateBefore,
List<StateMetadata> stateMetadataList,
List<InputProperty> inputProperties,
RowType outputType,
String description) |
StreamExecRank(ReadableConfig tableConfig,
RankType rankType,
PartitionSpec partitionSpec,
SortSpec sortSpec,
RankRange rankRange,
RankProcessStrategy rankStrategy,
boolean outputRankNumber,
boolean generateUpdateBefore,
InputProperty inputProperty,
RowType outputType,
String description) |
Modifier and Type | Method and Description |
---|---|
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
translateToPlan
supportFusionCodegen, translateToFusionCodegenSpec
public static final String RANK_TRANSFORMATION
public static final String FIELD_NAME_RANK_TYPE
public static final String FIELD_NAME_PARTITION_SPEC
public static final String FIELD_NAME_SORT_SPEC
public static final String FIELD_NAME_RANK_RANG
public static final String FIELD_NAME_RANK_STRATEGY
public static final String FIELD_NAME_GENERATE_UPDATE_BEFORE
public static final String FIELD_NAME_OUTPUT_RANK_NUMBER
public static final String STATE_NAME
public StreamExecRank(ReadableConfig tableConfig, RankType rankType, PartitionSpec partitionSpec, SortSpec sortSpec, RankRange rankRange, RankProcessStrategy rankStrategy, boolean outputRankNumber, boolean generateUpdateBefore, InputProperty inputProperty, RowType outputType, String description)
public StreamExecRank(int id, ExecNodeContext context, ReadableConfig persistedConfig, RankType rankType, PartitionSpec partitionSpec, SortSpec sortSpec, RankRange rankRange, RankProcessStrategy rankStrategy, boolean outputRankNumber, boolean generateUpdateBefore, @Nullable List<StateMetadata> stateMetadataList, List<InputProperty> inputProperties, 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
.Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.