Class PythonOperatorUtils
- java.lang.Object
-
- org.apache.flink.streaming.api.utils.PythonOperatorUtils
-
@Internal public class PythonOperatorUtils extends Object
Utilities used by Python operators.
-
-
Constructor Summary
Constructors Constructor Description PythonOperatorUtils()
-
Method Summary
All Methods Static Methods Concrete Methods Modifier and Type Method Description static <K> boolean
inBatchExecutionMode(org.apache.flink.runtime.state.KeyedStateBackend<K> stateBackend)
static <K> void
setCurrentKeyForStreaming(org.apache.flink.runtime.state.KeyedStateBackend<K> stateBackend, K currentKey)
Set the current key for streaming operator.static <K,N>
voidsetCurrentKeyForTimerService(org.apache.flink.streaming.api.operators.InternalTimerService<N> internalTimerService, K currentKey)
Set the current key for the timer service.
-
-
-
Method Detail
-
setCurrentKeyForStreaming
public static <K> void setCurrentKeyForStreaming(org.apache.flink.runtime.state.KeyedStateBackend<K> stateBackend, K currentKey)
Set the current key for streaming operator.
-
setCurrentKeyForTimerService
public static <K,N> void setCurrentKeyForTimerService(org.apache.flink.streaming.api.operators.InternalTimerService<N> internalTimerService, K currentKey) throws Exception
Set the current key for the timer service.- Throws:
Exception
-
inBatchExecutionMode
public static <K> boolean inBatchExecutionMode(org.apache.flink.runtime.state.KeyedStateBackend<K> stateBackend)
-
-