类 ProxyInternalTimeServiceManager<K>

  • 所有已实现的接口:
    org.apache.flink.streaming.api.operators.InternalTimeServiceManager<K>

    public class ProxyInternalTimeServiceManager<K>
    extends Object
    implements org.apache.flink.streaming.api.operators.InternalTimeServiceManager<K>
    Proxy InternalTimeServiceManager for the wrapped operators.
    • 嵌套类概要

      • 从接口继承的嵌套类/接口 org.apache.flink.streaming.api.operators.InternalTimeServiceManager

        org.apache.flink.streaming.api.operators.InternalTimeServiceManager.Provider
    • 构造器详细资料

      • ProxyInternalTimeServiceManager

        public ProxyInternalTimeServiceManager​(org.apache.flink.streaming.api.operators.InternalTimeServiceManager<K> wrappedManager,
                                               StateNamePrefix stateNamePrefix)
    • 方法详细资料

      • getInternalTimerService

        public <N> org.apache.flink.streaming.api.operators.InternalTimerService<N> getInternalTimerService​(String name,
                                                                                                            org.apache.flink.api.common.typeutils.TypeSerializer<K> keySerializer,
                                                                                                            org.apache.flink.api.common.typeutils.TypeSerializer<N> namespaceSerializer,
                                                                                                            org.apache.flink.streaming.api.operators.Triggerable<K,​N> triggerable)
        指定者:
        getInternalTimerService 在接口中 org.apache.flink.streaming.api.operators.InternalTimeServiceManager<K>
      • advanceWatermark

        public void advanceWatermark​(org.apache.flink.streaming.api.watermark.Watermark watermark)
                              throws Exception
        指定者:
        advanceWatermark 在接口中 org.apache.flink.streaming.api.operators.InternalTimeServiceManager<K>
        抛出:
        Exception
      • snapshotToRawKeyedState

        public void snapshotToRawKeyedState​(org.apache.flink.runtime.state.KeyedStateCheckpointOutputStream stateCheckpointOutputStream,
                                            String operatorName)
                                     throws Exception
        指定者:
        snapshotToRawKeyedState 在接口中 org.apache.flink.streaming.api.operators.InternalTimeServiceManager<K>
        抛出:
        Exception