Class Sum0AggFunction.DecimalSum0AggFunction
- java.lang.Object
-
- org.apache.flink.table.functions.UserDefinedFunction
-
- org.apache.flink.table.functions.DeclarativeAggregateFunction
-
- org.apache.flink.table.planner.functions.aggfunctions.Sum0AggFunction
-
- org.apache.flink.table.planner.functions.aggfunctions.Sum0AggFunction.DecimalSum0AggFunction
-
- All Implemented Interfaces:
Serializable
,FunctionDefinition
- Enclosing class:
- Sum0AggFunction
public static class Sum0AggFunction.DecimalSum0AggFunction extends Sum0AggFunction
Built-in Decimal Sum0 aggregate function.- See Also:
- Serialized Form
-
-
Nested Class Summary
-
Nested classes/interfaces inherited from class org.apache.flink.table.planner.functions.aggfunctions.Sum0AggFunction
Sum0AggFunction.ByteSum0AggFunction, Sum0AggFunction.DecimalSum0AggFunction, Sum0AggFunction.DoubleSum0AggFunction, Sum0AggFunction.FloatSum0AggFunction, Sum0AggFunction.IntSum0AggFunction, Sum0AggFunction.LongSum0AggFunction, Sum0AggFunction.ShortSum0AggFunction
-
-
Constructor Summary
Constructors Constructor Description DecimalSum0AggFunction(DecimalType decimalType)
-
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.Expression[]
initialValuesExpressions()
Expressions for initializing empty aggregation buffers.-
Methods inherited from class org.apache.flink.table.planner.functions.aggfunctions.Sum0AggFunction
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
-
DecimalSum0AggFunction
public DecimalSum0AggFunction(DecimalType decimalType)
-
-
Method Detail
-
getResultType
public DataType getResultType()
Description copied from class:DeclarativeAggregateFunction
The result type of the function.- Specified by:
getResultType
in classDeclarativeAggregateFunction
-
initialValuesExpressions
public Expression[] initialValuesExpressions()
Description copied from class:DeclarativeAggregateFunction
Expressions for initializing empty aggregation buffers.- Specified by:
initialValuesExpressions
in classDeclarativeAggregateFunction
-
adjustedPlus
protected UnresolvedCallExpression adjustedPlus(UnresolvedReferenceExpression arg1, UnresolvedReferenceExpression arg2)
- Overrides:
adjustedPlus
in classSum0AggFunction
-
adjustedMinus
protected UnresolvedCallExpression adjustedMinus(UnresolvedReferenceExpression arg1, UnresolvedReferenceExpression arg2)
- Overrides:
adjustedMinus
in classSum0AggFunction
-
-