程序包 | 说明 |
---|---|
org.apache.flink.table.functions.python | |
org.apache.flink.table.functions.python.utils |
限定符和类型 | 类和说明 |
---|---|
class |
BuiltInPythonAggregateFunction
The list of the built-in aggregate functions which can be mixed with the Python UDAF.
|
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.
|
限定符和类型 | 方法和说明 |
---|---|
PythonFunction |
PythonFunctionInfo.getPythonFunction() |
构造器和说明 |
---|
PythonAggregateFunctionInfo(PythonFunction pythonFunction,
Object[] inputs,
int filterArg,
boolean isDistinct) |
PythonFunctionInfo(PythonFunction pythonFunction,
Object[] inputs) |
限定符和类型 | 方法和说明 |
---|---|
static PythonFunction |
PythonFunctionUtils.getPythonFunction(String fullyQualifiedName,
org.apache.flink.configuration.ReadableConfig config,
ClassLoader classLoader) |
Copyright © 2014–2022 The Apache Software Foundation. All rights reserved.