Interface InternalProcessorContext

    • Method Detail

      • setSystemTimeMs

        void setSystemTimeMs​(long timeMs)
        Parameters:
        timeMs - current wall-clock system timestamp in milliseconds
      • currentSystemTimeMs

        long currentSystemTimeMs()
      • cache

        ThreadCache cache()
        Get the thread-global cache
      • initialize

        void initialize()
        Mark this context as being initialized
      • uninitialize

        void uninitialize()
        Mark this context as being uninitialized
      • taskType

        Task.TaskType taskType()
        Returns:
        the type of task (active/standby/global) that this context corresponds to
      • transitionToActive

        void transitionToActive​(StreamTask streamTask,
                                RecordCollector recordCollector,
                                ThreadCache newCache)
        Transition to active task and register a new task and cache to this processor context
      • transitionToStandby

        void transitionToStandby​(ThreadCache newCache)
        Transition to standby task and register a dummy cache to this processor context
      • getStateStore

        default <T extends StateStore> T getStateStore​(StoreBuilder<T> builder)
        Get a correctly typed state store, given a handle on the original builder.
      • logChange

        void logChange​(String storeName,
                       org.apache.kafka.common.utils.Bytes key,
                       byte[] value,
                       long timestamp)