Uses of Class
org.apache.flink.streaming.api.operators.python.process.AbstractExternalDataStreamPythonFunctionOperator
-
Packages that use AbstractExternalDataStreamPythonFunctionOperator Package Description org.apache.flink.streaming.api.operators.python.process -
-
Uses of AbstractExternalDataStreamPythonFunctionOperator in org.apache.flink.streaming.api.operators.python.process
Subclasses of AbstractExternalDataStreamPythonFunctionOperator in org.apache.flink.streaming.api.operators.python.process Modifier and Type Class Description class
AbstractExternalOneInputPythonFunctionOperator<IN,OUT>
AbstractExternalOneInputPythonFunctionOperator
is responsible for launching beam runner which will start a python harness to execute user defined python function.class
AbstractExternalTwoInputPythonFunctionOperator<IN1,IN2,OUT>
AbstractExternalTwoInputPythonFunctionOperator
is responsible for launching beam runner which will start a python harness to execute two-input user defined python function.class
ExternalPythonBatchCoBroadcastProcessOperator<IN1,IN2,OUT>
TheExternalPythonBatchCoBroadcastProcessOperator
is responsible for executing the Python CoBroadcastProcess Function under BATCH mode,ExternalPythonCoProcessOperator
is used under STREAMING mode.class
ExternalPythonBatchKeyedCoBroadcastProcessOperator<OUT>
TheExternalPythonBatchKeyedCoBroadcastProcessOperator
is responsible for executing the Python CoBroadcastProcess function under BATCH mode,ExternalPythonKeyedCoProcessOperator
is used under STREAMING mode.class
ExternalPythonCoProcessOperator<IN1,IN2,OUT>
TheExternalPythonCoProcessOperator
is responsible for executing the Python CoProcess Function.class
ExternalPythonKeyedCoProcessOperator<OUT>
ExternalPythonKeyedCoProcessOperator
is responsible for launching beam runner which will start a python harness to execute user defined python CoProcess function.class
ExternalPythonKeyedProcessOperator<OUT>
ExternalPythonKeyedProcessOperator
is responsible for launching beam runner which will start a python harness to execute user defined python function.class
ExternalPythonProcessOperator<IN,OUT>
ExternalPythonProcessOperator
is responsible for launching beam runner which will start a python harness to execute user defined python ProcessFunction.Methods in org.apache.flink.streaming.api.operators.python.process that return AbstractExternalDataStreamPythonFunctionOperator Modifier and Type Method Description <T> AbstractExternalDataStreamPythonFunctionOperator<T>
ExternalPythonCoProcessOperator. copy(DataStreamPythonFunctionInfo pythonFunctionInfo, TypeInformation<T> outputTypeInfo)
<T> AbstractExternalDataStreamPythonFunctionOperator<T>
ExternalPythonKeyedCoProcessOperator. copy(DataStreamPythonFunctionInfo pythonFunctionInfo, TypeInformation<T> outputTypeInfo)
<T> AbstractExternalDataStreamPythonFunctionOperator<T>
ExternalPythonKeyedProcessOperator. copy(DataStreamPythonFunctionInfo pythonFunctionInfo, TypeInformation<T> outputTypeInfo)
<T> AbstractExternalDataStreamPythonFunctionOperator<T>
ExternalPythonProcessOperator. copy(DataStreamPythonFunctionInfo pythonFunctionInfo, TypeInformation<T> outputTypeInfo)
-