Class DenseRankAggFunction
- 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.DenseRankAggFunction
-
- All Implemented Interfaces:
Serializable
,FunctionDefinition
public class DenseRankAggFunction extends RankLikeAggFunctionBase
built-in dense_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 DenseRankAggFunction(LogicalType[] orderKeyTypes)
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description Expression[]
accumulateExpressions()
Expressions for accumulating the mutable aggregation buffer based on an input row.UnresolvedReferenceExpression[]
aggBufferAttributes()
All fields of the aggregate buffer.DataType[]
getAggBufferTypes()
All types of the aggregate buffer.Expression[]
initialValuesExpressions()
Expressions for initializing empty aggregation buffers.-
Methods inherited from class org.apache.flink.table.planner.functions.aggfunctions.RankLikeAggFunctionBase
generateInitLiteral, getResultType, getValueExpression, 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
-
-
-
-
Constructor Detail
-
DenseRankAggFunction
public DenseRankAggFunction(LogicalType[] orderKeyTypes)
-
-
Method Detail
-
aggBufferAttributes
public UnresolvedReferenceExpression[] aggBufferAttributes()
Description copied from class:DeclarativeAggregateFunction
All fields of the aggregate buffer.- Specified by:
aggBufferAttributes
in classDeclarativeAggregateFunction
-
getAggBufferTypes
public DataType[] getAggBufferTypes()
Description copied from class:DeclarativeAggregateFunction
All types of the aggregate buffer.- Specified by:
getAggBufferTypes
in classDeclarativeAggregateFunction
-
initialValuesExpressions
public Expression[] initialValuesExpressions()
Description copied from class:DeclarativeAggregateFunction
Expressions for initializing empty aggregation buffers.- Specified by:
initialValuesExpressions
in classDeclarativeAggregateFunction
-
accumulateExpressions
public Expression[] accumulateExpressions()
Description copied from class:DeclarativeAggregateFunction
Expressions for accumulating the mutable aggregation buffer based on an input row.- Specified by:
accumulateExpressions
in classDeclarativeAggregateFunction
-
-