Uses of Class
org.apache.flink.table.functions.python.PythonEnv
-
-
Uses of PythonEnv in org.apache.flink.streaming.api.functions.python
Methods in org.apache.flink.streaming.api.functions.python that return PythonEnv Modifier and Type Method Description PythonEnv
DataStreamPythonFunction. getPythonEnv()
Constructors in org.apache.flink.streaming.api.functions.python with parameters of type PythonEnv Constructor Description DataStreamPythonFunction(byte[] serializedPythonFunction, PythonEnv pythonEnv)
-
Uses of PythonEnv in org.apache.flink.streaming.api.operators.python.process
Methods in org.apache.flink.streaming.api.operators.python.process that return PythonEnv Modifier and Type Method Description PythonEnv
AbstractExternalDataStreamPythonFunctionOperator. getPythonEnv()
abstract PythonEnv
AbstractExternalPythonFunctionOperator. getPythonEnv()
Returns thePythonEnv
used to create PythonEnvironmentManager.. -
Uses of PythonEnv in org.apache.flink.table.functions.python
Methods in org.apache.flink.table.functions.python that return PythonEnv Modifier and Type Method Description PythonEnv
BuiltInPythonAggregateFunction. getPythonEnv()
PythonEnv
PythonAggregateFunction. getPythonEnv()
PythonEnv
PythonFunction. getPythonEnv()
Returns the Python execution environment.PythonEnv
PythonScalarFunction. getPythonEnv()
PythonEnv
PythonTableAggregateFunction. getPythonEnv()
PythonEnv
PythonTableFunction. getPythonEnv()
Constructors in org.apache.flink.table.functions.python with parameters of type PythonEnv 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)
PythonScalarFunction(String name, byte[] serializedScalarFunction, String[] inputTypesString, String resultTypeString, PythonFunctionKind pythonFunctionKind, boolean deterministic, boolean takesRowAsInput, PythonEnv pythonEnv)
PythonScalarFunction(String name, byte[] serializedScalarFunction, PythonFunctionKind pythonFunctionKind, boolean deterministic, boolean takesRowAsInput, PythonEnv pythonEnv)
PythonScalarFunction(String name, byte[] serializedScalarFunction, DataType[] inputTypes, DataType resultType, PythonFunctionKind pythonFunctionKind, boolean deterministic, boolean takesRowAsInput, PythonEnv pythonEnv)
PythonTableAggregateFunction(String name, byte[] serializedTableAggregateFunction, String[] inputTypesString, String resultTypeString, String accumulatorTypeString, PythonFunctionKind pythonFunctionKind, boolean deterministic, boolean takesRowAsInput, PythonEnv pythonEnv)
PythonTableAggregateFunction(String name, byte[] serializedTableAggregateFunction, 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, String[] inputTypesString, String resultTypeString, PythonFunctionKind pythonFunctionKind, boolean deterministic, boolean takesRowAsInput, PythonEnv pythonEnv)
PythonTableFunction(String name, byte[] serializedScalarFunction, PythonFunctionKind pythonFunctionKind, boolean deterministic, boolean takesRowAsInput, PythonEnv pythonEnv)
PythonTableFunction(String name, byte[] serializedScalarFunction, DataType[] inputTypes, DataType resultType, PythonFunctionKind pythonFunctionKind, boolean deterministic, boolean takesRowAsInput, PythonEnv pythonEnv)
-
Uses of PythonEnv in org.apache.flink.table.runtime.operators.python.aggregate
Methods in org.apache.flink.table.runtime.operators.python.aggregate that return PythonEnv Modifier and Type Method Description PythonEnv
AbstractPythonStreamAggregateOperator. getPythonEnv()
-
Uses of PythonEnv in org.apache.flink.table.runtime.operators.python.aggregate.arrow
Methods in org.apache.flink.table.runtime.operators.python.aggregate.arrow that return PythonEnv Modifier and Type Method Description PythonEnv
AbstractArrowPythonAggregateFunctionOperator. getPythonEnv()
-
Uses of PythonEnv in org.apache.flink.table.runtime.operators.python.scalar
Methods in org.apache.flink.table.runtime.operators.python.scalar that return PythonEnv Modifier and Type Method Description PythonEnv
AbstractPythonScalarFunctionOperator. getPythonEnv()
-
Uses of PythonEnv in org.apache.flink.table.runtime.operators.python.table
Methods in org.apache.flink.table.runtime.operators.python.table that return PythonEnv Modifier and Type Method Description PythonEnv
PythonTableFunctionOperator. getPythonEnv()
-