Class PercentRankAggFunction
- java.lang.Object
-
- org.apache.flink.table.functions.UserDefinedFunction
-
- org.apache.flink.table.functions.DeclarativeAggregateFunction
-
- org.apache.flink.table.planner.functions.aggfunctions.RankLikeAggFunctionBase
-
- org.apache.flink.table.planner.functions.aggfunctions.RankAggFunction
-
- org.apache.flink.table.planner.functions.aggfunctions.PercentRankAggFunction
-
- All Implemented Interfaces:
Serializable
,FunctionDefinition
,SizeBasedWindowFunction
public class PercentRankAggFunction extends RankAggFunction implements SizeBasedWindowFunction
built-in percent_rank aggregate function.- See Also:
- Serialized Form
-
-
Field Summary
-
Fields inherited from class org.apache.flink.table.planner.functions.aggfunctions.RankLikeAggFunctionBase
lastValues, orderKeyTypes, sequence
-
-
Constructor Summary
Constructors Constructor Description PercentRankAggFunction(LogicalType[] orderKeyTypes)
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description Expression
getValueExpression()
An expression which returns the final value for this aggregate function.-
Methods inherited from class org.apache.flink.table.planner.functions.aggfunctions.RankAggFunction
accumulateExpressions, aggBufferAttributes, getAggBufferTypes, initialValuesExpressions
-
Methods inherited from class org.apache.flink.table.planner.functions.aggfunctions.RankLikeAggFunctionBase
generateInitLiteral, getResultType, mergeExpressions, operandCount, orderKeyEqualsExpression, retractExpressions
-
Methods inherited from class org.apache.flink.table.functions.DeclarativeAggregateFunction
getKind, getTypeInference, mergeOperand, mergeOperands, operand, operands
-
Methods inherited from class org.apache.flink.table.functions.UserDefinedFunction
close, functionIdentifier, open, toString
-
Methods inherited from class java.lang.Object
clone, equals, finalize, getClass, hashCode, notify, notifyAll, wait, wait, wait
-
Methods inherited from interface org.apache.flink.table.functions.FunctionDefinition
getRequirements, isDeterministic, supportsConstantFolding
-
Methods inherited from interface org.apache.flink.table.planner.functions.aggfunctions.SizeBasedWindowFunction
windowSizeAttribute
-
-
-
-
Constructor Detail
-
PercentRankAggFunction
public PercentRankAggFunction(LogicalType[] orderKeyTypes)
-
-
Method Detail
-
getValueExpression
public Expression getValueExpression()
Description copied from class:DeclarativeAggregateFunction
An expression which returns the final value for this aggregate function.- Overrides:
getValueExpression
in classRankLikeAggFunctionBase
-
-