@Internal public class PythonOperatorUtils extends Object
构造器和说明 |
---|
PythonOperatorUtils() |
限定符和类型 | 方法和说明 |
---|---|
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> void |
setCurrentKeyForTimerService(org.apache.flink.streaming.api.operators.InternalTimerService<N> internalTimerService,
K currentKey)
Set the current key for the timer service.
|
public static <K> void setCurrentKeyForStreaming(org.apache.flink.runtime.state.KeyedStateBackend<K> stateBackend, K currentKey)
public static <K,N> void setCurrentKeyForTimerService(org.apache.flink.streaming.api.operators.InternalTimerService<N> internalTimerService, K currentKey) throws Exception
Exception
public static <K> boolean inBatchExecutionMode(org.apache.flink.runtime.state.KeyedStateBackend<K> stateBackend)
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.