Uses of Interface
org.apache.flink.python.PythonFunctionRunner
-
-
Uses of PythonFunctionRunner in org.apache.flink.streaming.api.operators.python.process
Fields in org.apache.flink.streaming.api.operators.python.process declared as PythonFunctionRunner Modifier and Type Field Description protected PythonFunctionRunner
AbstractExternalPythonFunctionOperator. pythonFunctionRunner
ThePythonFunctionRunner
which is responsible for Python user-defined function execution.Methods in org.apache.flink.streaming.api.operators.python.process that return PythonFunctionRunner Modifier and Type Method Description abstract PythonFunctionRunner
AbstractExternalPythonFunctionOperator. createPythonFunctionRunner()
Creates thePythonFunctionRunner
which is responsible for Python user-defined function execution.PythonFunctionRunner
ExternalPythonCoProcessOperator. createPythonFunctionRunner()
PythonFunctionRunner
ExternalPythonKeyedCoProcessOperator. createPythonFunctionRunner()
PythonFunctionRunner
ExternalPythonKeyedProcessOperator. createPythonFunctionRunner()
PythonFunctionRunner
ExternalPythonProcessOperator. createPythonFunctionRunner()
-
Uses of PythonFunctionRunner in org.apache.flink.streaming.api.runners.python.beam
Classes in org.apache.flink.streaming.api.runners.python.beam that implement PythonFunctionRunner Modifier and Type Class Description class
BeamDataStreamPythonFunctionRunner
BeamDataStreamPythonFunctionRunner
is responsible for starting a beam python harness to execute user defined python function.class
BeamPythonFunctionRunner
ABeamPythonFunctionRunner
used to execute Python functions. -
Uses of PythonFunctionRunner in org.apache.flink.table.runtime.operators.python
Methods in org.apache.flink.table.runtime.operators.python that return PythonFunctionRunner Modifier and Type Method Description PythonFunctionRunner
AbstractStatelessFunctionOperator. createPythonFunctionRunner()
-
Uses of PythonFunctionRunner in org.apache.flink.table.runtime.operators.python.aggregate
Methods in org.apache.flink.table.runtime.operators.python.aggregate that return PythonFunctionRunner Modifier and Type Method Description PythonFunctionRunner
AbstractPythonStreamAggregateOperator. createPythonFunctionRunner()
-
Uses of PythonFunctionRunner in org.apache.flink.table.runtime.runners.python.beam
Classes in org.apache.flink.table.runtime.runners.python.beam that implement PythonFunctionRunner Modifier and Type Class Description class
BeamTablePythonFunctionRunner
ABeamTablePythonFunctionRunner
used to execute Python functions in Table API.
-