Class BuiltInAggregateFunction<T,​ACC>

    • Constructor Summary

      Constructors 
      Modifier Constructor Description
      protected BuiltInAggregateFunction()  
      protected BuiltInAggregateFunction​(org.apache.flink.table.functions.BuiltInFunctionDefinition definition, org.apache.flink.table.functions.SpecializedFunction.SpecializedContext context)  
    • Method Summary

      All Methods Instance Methods Concrete Methods 
      Modifier and Type Method Description
      org.apache.flink.table.types.DataType getAccumulatorDataType()  
      List<org.apache.flink.table.types.DataType> getArgumentDataTypes()  
      org.apache.flink.table.types.DataType getOutputDataType()  
      Set<org.apache.flink.table.functions.FunctionRequirement> getRequirements()  
      org.apache.flink.table.types.inference.TypeInference getTypeInference​(org.apache.flink.table.catalog.DataTypeFactory typeFactory)  
      boolean isDeterministic()  
      • Methods inherited from class org.apache.flink.table.functions.AggregateFunction

        getKind, getValue
      • Methods inherited from class org.apache.flink.table.functions.ImperativeAggregateFunction

        createAccumulator, getAccumulatorType, getResultType
      • Methods inherited from class org.apache.flink.table.functions.UserDefinedFunction

        close, functionIdentifier, open, toString
      • Methods inherited from interface org.apache.flink.table.functions.FunctionDefinition

        supportsConstantFolding
    • Constructor Detail

      • BuiltInAggregateFunction

        protected BuiltInAggregateFunction​(org.apache.flink.table.functions.BuiltInFunctionDefinition definition,
                                           org.apache.flink.table.functions.SpecializedFunction.SpecializedContext context)
      • BuiltInAggregateFunction

        protected BuiltInAggregateFunction()
    • Method Detail

      • getArgumentDataTypes

        public List<org.apache.flink.table.types.DataType> getArgumentDataTypes()
      • getAccumulatorDataType

        public org.apache.flink.table.types.DataType getAccumulatorDataType()
      • getOutputDataType

        public org.apache.flink.table.types.DataType getOutputDataType()
      • getTypeInference

        public org.apache.flink.table.types.inference.TypeInference getTypeInference​(org.apache.flink.table.catalog.DataTypeFactory typeFactory)
        Specified by:
        getTypeInference in interface org.apache.flink.table.functions.FunctionDefinition
        Overrides:
        getTypeInference in class org.apache.flink.table.functions.AggregateFunction<T,​ACC>
      • getRequirements

        public Set<org.apache.flink.table.functions.FunctionRequirement> getRequirements()
      • isDeterministic

        public boolean isDeterministic()