Class AvgAggFunction.DecimalAvgAggFunction
- java.lang.Object
-
- org.apache.flink.table.functions.UserDefinedFunction
-
- org.apache.flink.table.functions.DeclarativeAggregateFunction
-
- org.apache.flink.table.planner.functions.aggfunctions.AvgAggFunction
-
- org.apache.flink.table.planner.functions.aggfunctions.AvgAggFunction.DecimalAvgAggFunction
-
- All Implemented Interfaces:
Serializable
,FunctionDefinition
- Enclosing class:
- AvgAggFunction
public static class AvgAggFunction.DecimalAvgAggFunction extends AvgAggFunction
Built-in Decimal Avg aggregate function.- See Also:
- Serialized Form
-
-
Nested Class Summary
-
Nested classes/interfaces inherited from class org.apache.flink.table.planner.functions.aggfunctions.AvgAggFunction
AvgAggFunction.ByteAvgAggFunction, AvgAggFunction.DecimalAvgAggFunction, AvgAggFunction.DoubleAvgAggFunction, AvgAggFunction.FloatAvgAggFunction, AvgAggFunction.IntAvgAggFunction, AvgAggFunction.LongAvgAggFunction, AvgAggFunction.ShortAvgAggFunction
-
-
Constructor Summary
Constructors Constructor Description DecimalAvgAggFunction(DecimalType type)
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description protected UnresolvedCallExpression
adjustedMinus(UnresolvedReferenceExpression arg1, UnresolvedReferenceExpression arg2)
protected UnresolvedCallExpression
adjustedPlus(UnresolvedReferenceExpression arg1, UnresolvedReferenceExpression arg2)
DataType
getResultType()
The result type of the function.DataType
getSumType()
Expression[]
initialValuesExpressions()
Expressions for initializing empty aggregation buffers.-
Methods inherited from class org.apache.flink.table.planner.functions.aggfunctions.AvgAggFunction
accumulateExpressions, aggBufferAttributes, getAggBufferTypes, getValueExpression, mergeExpressions, operandCount, 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
-
DecimalAvgAggFunction
public DecimalAvgAggFunction(DecimalType type)
-
-
Method Detail
-
getResultType
public DataType getResultType()
Description copied from class:DeclarativeAggregateFunction
The result type of the function.- Specified by:
getResultType
in classDeclarativeAggregateFunction
-
getSumType
public DataType getSumType()
- Specified by:
getSumType
in classAvgAggFunction
-
initialValuesExpressions
public Expression[] initialValuesExpressions()
Description copied from class:DeclarativeAggregateFunction
Expressions for initializing empty aggregation buffers.- Overrides:
initialValuesExpressions
in classAvgAggFunction
-
adjustedPlus
protected UnresolvedCallExpression adjustedPlus(UnresolvedReferenceExpression arg1, UnresolvedReferenceExpression arg2)
- Overrides:
adjustedPlus
in classAvgAggFunction
-
adjustedMinus
protected UnresolvedCallExpression adjustedMinus(UnresolvedReferenceExpression arg1, UnresolvedReferenceExpression arg2)
- Overrides:
adjustedMinus
in classAvgAggFunction
-
-