Class PythonOperatorUtils


  • @Internal
    public class PythonOperatorUtils
    extends Object
    Utilities used by Python operators.
    • Constructor Detail

      • PythonOperatorUtils

        public PythonOperatorUtils()
    • 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)