Package | Description |
---|---|
org.apache.flink.table.functions.python |
Modifier and Type | Method and Description |
---|---|
PythonEnv |
PythonTableFunction.getPythonEnv() |
PythonEnv |
PythonTableAggregateFunction.getPythonEnv() |
PythonEnv |
BuiltInPythonAggregateFunction.getPythonEnv() |
PythonEnv |
PythonAggregateFunction.getPythonEnv() |
PythonEnv |
PythonFunction.getPythonEnv()
Returns the Python execution environment.
|
PythonEnv |
PythonScalarFunction.getPythonEnv() |
Constructor and Description |
---|
PythonAggregateFunction(String name,
byte[] serializedAggregateFunction,
DataType[] inputTypes,
DataType resultType,
DataType accumulatorType,
PythonFunctionKind pythonFunctionKind,
boolean deterministic,
boolean takesRowAsInput,
PythonEnv pythonEnv) |
PythonScalarFunction(String name,
byte[] serializedScalarFunction,
org.apache.flink.api.common.typeinfo.TypeInformation[] inputTypes,
org.apache.flink.api.common.typeinfo.TypeInformation resultType,
PythonFunctionKind pythonFunctionKind,
boolean deterministic,
boolean takesRowAsInput,
PythonEnv pythonEnv) |
PythonTableAggregateFunction(String name,
byte[] serializedTableAggregateFunction,
DataType[] inputTypes,
DataType resultType,
DataType accumulatorType,
PythonFunctionKind pythonFunctionKind,
boolean deterministic,
boolean takesRowAsInput,
PythonEnv pythonEnv) |
PythonTableFunction(String name,
byte[] serializedScalarFunction,
org.apache.flink.api.common.typeinfo.TypeInformation[] inputTypes,
org.apache.flink.api.java.typeutils.RowTypeInfo resultType,
PythonFunctionKind pythonFunctionKind,
boolean deterministic,
boolean takesRowAsInput,
PythonEnv pythonEnv) |
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.