Class DeclarativeAggregateFunction

    • Constructor Detail

      • DeclarativeAggregateFunction

        public DeclarativeAggregateFunction()
    • Method Detail

      • operandCount

        public abstract int operandCount()
        How many operands your function will deal with.
      • getAggBufferTypes

        public abstract DataType[] getAggBufferTypes()
        All types of the aggregate buffer.
      • getResultType

        public abstract DataType getResultType()
        The result type of the function.
      • initialValuesExpressions

        public abstract Expression[] initialValuesExpressions()
        Expressions for initializing empty aggregation buffers.
      • accumulateExpressions

        public abstract Expression[] accumulateExpressions()
        Expressions for accumulating the mutable aggregation buffer based on an input row.
      • retractExpressions

        public abstract Expression[] retractExpressions()
        Expressions for retracting the mutable aggregation buffer based on an input row.
      • mergeExpressions

        public abstract Expression[] mergeExpressions()
        A sequence of expressions for merging two aggregation buffers together. When defining these expressions, you can use the syntax attributeName and mergeOperand(attributeName) to refer to the attributes corresponding to each of the buffers being merged.
      • getValueExpression

        public abstract Expression getValueExpression()
        An expression which returns the final value for this aggregate function.
      • operands

        public final UnresolvedReferenceExpression[] operands()
        Args of accumulate and retract, the input value (usually obtained from a new arrived data).
      • operand

        public final UnresolvedReferenceExpression operand​(int i)
        Arg of accumulate and retract, the input value (usually obtained from a new arrived data).
      • getKind

        public FunctionKind getKind()
        Description copied from interface: FunctionDefinition
        Returns the kind of function this definition describes.
      • getTypeInference

        public TypeInference getTypeInference​(DataTypeFactory factory)
        Description copied from class: UserDefinedFunction
        Returns the logic for performing type inference of a call to this function definition.

        The type inference process is responsible for inferring unknown types of input arguments, validating input arguments, and producing result types. The type inference process happens independent of a function body. The output of the type inference is used to search for a corresponding runtime implementation.

        Instances of type inference can be created by using TypeInference.newBuilder().

        See BuiltInFunctionDefinitions for concrete usage examples.

        The type inference for user-defined functions is automatically extracted using reflection. It does this by analyzing implementation methods such as eval() or accumulate() and the generic parameters of a function class if present. If the reflective information is not sufficient, it can be supported and enriched with DataTypeHint and FunctionHint annotations.

        Note: Overriding this method is only recommended for advanced users. If a custom type inference is specified, it is the responsibility of the implementer to make sure that the output of the type inference process matches with the implementation method:

        The implementation method must comply with each DataType.getConversionClass() returned by the type inference. For example, if DataTypes.TIMESTAMP(3).bridgedTo(java.sql.Timestamp.class) is an expected argument type, the method must accept a call eval(java.sql.Timestamp).

        Regular Java calling semantics (including type widening and autoboxing) are applied when calling an implementation method which means that the signature can be eval(java.lang.Object).

        The runtime will take care of converting the data to the data format specified by the DataType.getConversionClass() coming from the type inference logic.

        Specified by:
        getTypeInference in interface FunctionDefinition
        Specified by:
        getTypeInference in class UserDefinedFunction