Class PythonAggregateFunction
- java.lang.Object
-
- org.apache.flink.table.functions.UserDefinedFunction
-
- org.apache.flink.table.functions.ImperativeAggregateFunction<T,ACC>
-
- org.apache.flink.table.functions.AggregateFunction
-
- org.apache.flink.table.functions.python.PythonAggregateFunction
-
- All Implemented Interfaces:
Serializable,FunctionDefinition,PythonFunction
@Internal public class PythonAggregateFunction extends AggregateFunction implements PythonFunction
The wrapper of user defined python aggregate function.- See Also:
- Serialized Form
-
-
Constructor Summary
Constructors Constructor Description PythonAggregateFunction(String name, byte[] serializedAggregateFunction, String[] inputTypesString, String resultTypeString, String accumulatorTypeString, PythonFunctionKind pythonFunctionKind, boolean deterministic, boolean takesRowAsInput, PythonEnv pythonEnv)PythonAggregateFunction(String name, byte[] serializedAggregateFunction, PythonFunctionKind pythonFunctionKind, boolean deterministic, boolean takesRowAsInput, PythonEnv pythonEnv)PythonAggregateFunction(String name, byte[] serializedAggregateFunction, DataType[] inputTypes, DataType resultType, DataType accumulatorType, PythonFunctionKind pythonFunctionKind, boolean deterministic, boolean takesRowAsInput, PythonEnv pythonEnv)
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description voidaccumulate(Object accumulator, Object... args)ObjectcreateAccumulator()Creates and initializes the accumulator for thisImperativeAggregateFunction.org.apache.flink.api.common.typeinfo.TypeInformationgetAccumulatorType()Returns theTypeInformationof theImperativeAggregateFunction's accumulator.PythonEnvgetPythonEnv()Returns the Python execution environment.PythonFunctionKindgetPythonFunctionKind()Returns the kind of the user-defined python function.org.apache.flink.api.common.typeinfo.TypeInformationgetResultType()Returns theTypeInformationof theImperativeAggregateFunction's result.byte[]getSerializedPythonFunction()Returns the serialized representation of the user-defined python function.TypeInferencegetTypeInference(DataTypeFactory typeFactory)Returns the logic for performing type inference of a call to this function definition.ObjectgetValue(Object accumulator)Called every time when an aggregation result should be materialized.booleanisDeterministic()Returns information about the determinism of the function's results.booleantakesRowAsInput()Returns Whether the Python function takes row as input instead of each columns of a row.StringtoString()Returns the name of the UDF that is used for plan explanation and logging.-
Methods inherited from class org.apache.flink.table.functions.AggregateFunction
getKind
-
Methods inherited from class org.apache.flink.table.functions.UserDefinedFunction
close, functionIdentifier, open
-
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, supportsConstantFolding
-
-
-
-
Constructor Detail
-
PythonAggregateFunction
public PythonAggregateFunction(String name, byte[] serializedAggregateFunction, DataType[] inputTypes, DataType resultType, DataType accumulatorType, PythonFunctionKind pythonFunctionKind, boolean deterministic, boolean takesRowAsInput, PythonEnv pythonEnv)
-
PythonAggregateFunction
public PythonAggregateFunction(String name, byte[] serializedAggregateFunction, String[] inputTypesString, String resultTypeString, String accumulatorTypeString, PythonFunctionKind pythonFunctionKind, boolean deterministic, boolean takesRowAsInput, PythonEnv pythonEnv)
-
PythonAggregateFunction
public PythonAggregateFunction(String name, byte[] serializedAggregateFunction, PythonFunctionKind pythonFunctionKind, boolean deterministic, boolean takesRowAsInput, PythonEnv pythonEnv)
-
-
Method Detail
-
getValue
public Object getValue(Object accumulator)
Description copied from class:AggregateFunctionCalled every time when an aggregation result should be materialized. The returned value could be either an early and incomplete result (periodically emitted as data arrives) or the final result of the aggregation.- Specified by:
getValuein classAggregateFunction- Parameters:
accumulator- the accumulator which contains the current intermediate results- Returns:
- the aggregation result
-
createAccumulator
public Object createAccumulator()
Description copied from class:ImperativeAggregateFunctionCreates and initializes the accumulator for thisImperativeAggregateFunction.The accumulator is an intermediate data structure that stores the aggregated values until a final aggregation result is computed.
- Specified by:
createAccumulatorin classImperativeAggregateFunction- Returns:
- the accumulator with the initial value
-
getSerializedPythonFunction
public byte[] getSerializedPythonFunction()
Description copied from interface:PythonFunctionReturns the serialized representation of the user-defined python function.- Specified by:
getSerializedPythonFunctionin interfacePythonFunction
-
getPythonEnv
public PythonEnv getPythonEnv()
Description copied from interface:PythonFunctionReturns the Python execution environment.- Specified by:
getPythonEnvin interfacePythonFunction
-
getPythonFunctionKind
public PythonFunctionKind getPythonFunctionKind()
Description copied from interface:PythonFunctionReturns the kind of the user-defined python function.- Specified by:
getPythonFunctionKindin interfacePythonFunction
-
takesRowAsInput
public boolean takesRowAsInput()
Description copied from interface:PythonFunctionReturns Whether the Python function takes row as input instead of each columns of a row.- Specified by:
takesRowAsInputin interfacePythonFunction
-
isDeterministic
public boolean isDeterministic()
Description copied from interface:FunctionDefinitionReturns information about the determinism of the function's results.It returns
trueif and only if a call to this function is guaranteed to always return the same result given the same parameters.trueis assumed by default. If the function is not purely functional likerandom(), date(), now(), ...this method must returnfalse.Furthermore, return
falseif the planner should always execute this function on the cluster side. In other words: the planner should not perform constant expression reduction during planning for constant calls to this function.- Specified by:
isDeterministicin interfaceFunctionDefinition
-
getResultType
public org.apache.flink.api.common.typeinfo.TypeInformation getResultType()
Description copied from class:ImperativeAggregateFunctionReturns theTypeInformationof theImperativeAggregateFunction's result.- Overrides:
getResultTypein classImperativeAggregateFunction- Returns:
- The
TypeInformationof theImperativeAggregateFunction's result ornullif the result type should be automatically inferred.
-
getAccumulatorType
public org.apache.flink.api.common.typeinfo.TypeInformation getAccumulatorType()
Description copied from class:ImperativeAggregateFunctionReturns theTypeInformationof theImperativeAggregateFunction's accumulator.- Overrides:
getAccumulatorTypein classImperativeAggregateFunction- Returns:
- The
TypeInformationof theImperativeAggregateFunction's accumulator ornullif the accumulator type should be automatically inferred.
-
getTypeInference
public TypeInference getTypeInference(DataTypeFactory typeFactory)
Description copied from class:UserDefinedFunctionReturns 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
BuiltInFunctionDefinitionsfor 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 withDataTypeHintandFunctionHintannotations.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, ifDataTypes.TIMESTAMP(3).bridgedTo(java.sql.Timestamp.class)is an expected argument type, the method must accept a calleval(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:
getTypeInferencein interfaceFunctionDefinition- Overrides:
getTypeInferencein classAggregateFunction
-
toString
public String toString()
Description copied from class:UserDefinedFunctionReturns the name of the UDF that is used for plan explanation and logging.- Overrides:
toStringin classUserDefinedFunction
-
-