Interface WindowReaderFunction.Context<W extends org.apache.flink.streaming.api.windowing.windows.Window>

  • All Superinterfaces:
    Serializable
    Enclosing class:
    WindowReaderFunction<IN,​OUT,​KEY,​W extends org.apache.flink.streaming.api.windowing.windows.Window>

    public static interface WindowReaderFunction.Context<W extends org.apache.flink.streaming.api.windowing.windows.Window>
    extends Serializable
    The context holding window metadata.
    • Method Summary

      All Methods Instance Methods Abstract Methods 
      Modifier and Type Method Description
      org.apache.flink.api.common.state.KeyedStateStore globalState()
      State accessor for per-key global state.
      Set<Long> registeredEventTimeTimers()  
      Set<Long> registeredProcessingTimeTimers()  
      <S extends org.apache.flink.api.common.state.State>
      S
      triggerState​(org.apache.flink.api.common.state.StateDescriptor<S,​?> descriptor)
      Retrieves a State object that can be used to interact with fault-tolerant state that is scoped to the trigger which corresponds to the current window.
      W window()
      Returns the window that is being evaluated.
      org.apache.flink.api.common.state.KeyedStateStore windowState()
      State accessor for per-key and per-window state.
    • Method Detail

      • window

        W window()
        Returns the window that is being evaluated.
      • triggerState

        <S extends org.apache.flink.api.common.state.State> S triggerState​(org.apache.flink.api.common.state.StateDescriptor<S,​?> descriptor)
        Retrieves a State object that can be used to interact with fault-tolerant state that is scoped to the trigger which corresponds to the current window.
        Type Parameters:
        S - The type of the state.
        Parameters:
        descriptor - The StateDescriptor that contains the name and type of the state that is being accessed.
        Returns:
        The partitioned state object.
      • windowState

        org.apache.flink.api.common.state.KeyedStateStore windowState()
        State accessor for per-key and per-window state.
      • globalState

        org.apache.flink.api.common.state.KeyedStateStore globalState()
        State accessor for per-key global state.
      • registeredEventTimeTimers

        Set<Long> registeredEventTimeTimers()
                                     throws Exception
        Returns:
        All event time timers registered by a trigger for the current window.
        Throws:
        Exception
      • registeredProcessingTimeTimers

        Set<Long> registeredProcessingTimeTimers()
                                          throws Exception
        Returns:
        All processing time timers registered by a trigger for the current window.
        Throws:
        Exception