Uses of Class
org.apache.flink.table.functions.UserDefinedFunction
-
Packages that use UserDefinedFunction Package Description org.apache.flink.table.functions org.apache.flink.table.functions.python -
-
Uses of UserDefinedFunction in org.apache.flink.table.functions
Subclasses of UserDefinedFunction in org.apache.flink.table.functions Modifier and Type Class Description class
AggregateFunction<T,ACC>
Base class for a user-defined aggregate function.class
AsyncLookupFunction
A wrapper class ofAsyncTableFunction
for asynchronously lookup rows matching the lookup keys from external system.class
AsyncScalarFunction
Base class for a user-defined scalar function which returns results asynchronously.class
AsyncTableFunction<T>
Base class for a user-defined asynchronous table function.class
ImperativeAggregateFunction<T,ACC>
Base class for user-definedAggregateFunction
andTableAggregateFunction
.class
LookupFunction
A wrapper class ofTableFunction
for synchronously lookup rows matching the lookup keys from external system.class
ScalarFunction
Base class for a user-defined scalar function.class
TableAggregateFunction<T,ACC>
Base class for a user-defined table aggregate function.class
TableFunction<T>
Base class for a user-defined table function.class
TemporalTableFunction
Class representing temporal table function over some history table.Methods in org.apache.flink.table.functions that return UserDefinedFunction Modifier and Type Method Description static UserDefinedFunction
UserDefinedFunctionHelper. createSpecializedFunction(String functionName, FunctionDefinition definition, CallContext callContext, ClassLoader builtInClassLoader, org.apache.flink.configuration.ReadableConfig configuration, SpecializedFunction.ExpressionEvaluatorFactory evaluatorFactory)
Creates the runtime implementation of aFunctionDefinition
as an instance ofUserDefinedFunction
.static UserDefinedFunction
UserDefinedFunctionHelper. instantiateFunction(Class<?> functionClass)
Instantiates aUserDefinedFunction
assuming a JVM function with default constructor.static UserDefinedFunction
UserDefinedFunctionHelper. instantiateFunction(ClassLoader classLoader, org.apache.flink.configuration.ReadableConfig config, String name, CatalogFunction catalogFunction)
Instantiates aUserDefinedFunction
from aCatalogFunction
.UserDefinedFunction
BuiltInFunctionDefinition. specialize(SpecializedFunction.SpecializedContext context)
UserDefinedFunction
SpecializedFunction. specialize(SpecializedFunction.SpecializedContext context)
Provides a runtime implementation that is specialized for the given call and session.Methods in org.apache.flink.table.functions with parameters of type UserDefinedFunction Modifier and Type Method Description static String
UserDefinedFunctionHelper. generateInlineFunctionName(UserDefinedFunction function)
Name for anonymous, inline functions.static boolean
UserDefinedFunctionHelper. isClassNameSerializable(UserDefinedFunction function)
Returns whether aUserDefinedFunction
can be easily serialized and identified by only a fully qualified class name.static void
UserDefinedFunctionHelper. prepareInstance(org.apache.flink.configuration.ReadableConfig config, UserDefinedFunction function)
Prepares aUserDefinedFunction
instance for usage in the API.Method parameters in org.apache.flink.table.functions with type arguments of type UserDefinedFunction Modifier and Type Method Description static void
UserDefinedFunctionHelper. validateClass(Class<? extends UserDefinedFunction> functionClass)
Validates aUserDefinedFunction
class for usage in the API.static void
UserDefinedFunctionHelper. validateClassForRuntime(Class<? extends UserDefinedFunction> functionClass, String methodName, Class<?>[] argumentClasses, Class<?> outputClass, String functionName)
Validates aUserDefinedFunction
class for usage in the runtime. -
Uses of UserDefinedFunction in org.apache.flink.table.functions.python
Subclasses of UserDefinedFunction in org.apache.flink.table.functions.python Modifier and Type Class Description class
PythonAggregateFunction
The wrapper of user defined python aggregate function.class
PythonScalarFunction
The wrapper of user defined python scalar function.class
PythonTableAggregateFunction
The wrapper of user defined python table aggregate function.class
PythonTableFunction
The wrapper of user defined python table function.
-