Package | Description |
---|---|
org.apache.flink.streaming.api.operators.python.embedded |
Modifier and Type | Class and Description |
---|---|
class |
AbstractOneInputEmbeddedPythonFunctionOperator<IN,OUT>
AbstractOneInputEmbeddedPythonFunctionOperator is responsible for run Python DataStream
operators with one input in Embedded Python environment. |
class |
AbstractTwoInputEmbeddedPythonFunctionOperator<IN1,IN2,OUT>
AbstractTwoInputEmbeddedPythonFunctionOperator is responsible for run Python DataStream
operators with two input user defined python function in Embedded Python environment. |
class |
EmbeddedPythonBatchCoBroadcastProcessOperator<IN1,IN2,OUT>
The
EmbeddedPythonBatchCoBroadcastProcessOperator is responsible for executing the Python
CoBroadcastProcess Function under BATCH mode, EmbeddedPythonCoProcessOperator is used
under STREAMING mode. |
class |
EmbeddedPythonBatchKeyedCoBroadcastProcessOperator<K,IN1,IN2,OUT>
The
EmbeddedPythonBatchKeyedCoBroadcastProcessOperator is responsible for executing the
Python CoBroadcastProcess function under BATCH mode, EmbeddedPythonKeyedCoProcessOperator
is used under STREAMING mode. |
class |
EmbeddedPythonCoProcessOperator<IN1,IN2,OUT>
EmbeddedPythonCoProcessOperator is responsible for executing Python CoProcessFunction in
embedded Python environment. |
class |
EmbeddedPythonKeyedCoProcessOperator<K,IN1,IN2,OUT>
EmbeddedPythonKeyedCoProcessOperator is responsible for executing user defined python
KeyedCoProcessFunction in embedded Python environment. |
class |
EmbeddedPythonKeyedProcessOperator<K,IN,OUT>
EmbeddedPythonKeyedProcessOperator is responsible for executing user defined python
KeyedProcessFunction in embedded Python environment. |
class |
EmbeddedPythonProcessOperator<IN,OUT>
EmbeddedPythonProcessOperator is responsible for executing Python ProcessFunction in
embedded Python environment. |
class |
EmbeddedPythonWindowOperator<K,IN,OUT,W extends Window>
EmbeddedPythonWindowOperator is responsible for executing user defined python
ProcessWindowFunction in embedded Python environment. |
Modifier and Type | Method and Description |
---|---|
<T> AbstractEmbeddedDataStreamPythonFunctionOperator<T> |
EmbeddedPythonProcessOperator.copy(DataStreamPythonFunctionInfo pythonFunctionInfo,
TypeInformation<T> outputTypeInfo) |
<T> AbstractEmbeddedDataStreamPythonFunctionOperator<T> |
EmbeddedPythonKeyedProcessOperator.copy(DataStreamPythonFunctionInfo pythonFunctionInfo,
TypeInformation<T> outputTypeInfo) |
<T> AbstractEmbeddedDataStreamPythonFunctionOperator<T> |
EmbeddedPythonCoProcessOperator.copy(DataStreamPythonFunctionInfo pythonFunctionInfo,
TypeInformation<T> outputTypeInfo) |
<T> AbstractEmbeddedDataStreamPythonFunctionOperator<T> |
EmbeddedPythonKeyedCoProcessOperator.copy(DataStreamPythonFunctionInfo pythonFunctionInfo,
TypeInformation<T> outputTypeInfo) |
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.