Class GlobalStreamThread

  • All Implemented Interfaces:
    java.lang.Runnable

    public class GlobalStreamThread
    extends java.lang.Thread
    This is the thread responsible for keeping all Global State Stores updated. It delegates most of the responsibility to the internal class StateConsumer
    • Nested Class Summary

      Nested Classes 
      Modifier and Type Class Description
      static class  GlobalStreamThread.State
      The states that the global stream thread can be in
      • Nested classes/interfaces inherited from class java.lang.Thread

        java.lang.Thread.UncaughtExceptionHandler
    • Field Summary

      • Fields inherited from class java.lang.Thread

        MAX_PRIORITY, MIN_PRIORITY, NORM_PRIORITY
    • Method Summary

      All Methods Instance Methods Concrete Methods 
      Modifier and Type Method Description
      java.util.Map<org.apache.kafka.common.MetricName,​org.apache.kafka.common.Metric> consumerMetrics()  
      void run()  
      void setStateListener​(StreamThread.StateListener listener)
      Set the StreamThread.StateListener to be notified when state changes.
      void shutdown()  
      void start()  
      GlobalStreamThread.State state()  
      boolean stillRunning()  
      • Methods inherited from class java.lang.Thread

        activeCount, checkAccess, clone, countStackFrames, currentThread, dumpStack, enumerate, getAllStackTraces, getContextClassLoader, getDefaultUncaughtExceptionHandler, getId, getName, getPriority, getStackTrace, getState, getThreadGroup, getUncaughtExceptionHandler, holdsLock, interrupt, interrupted, isAlive, isDaemon, isInterrupted, join, join, join, onSpinWait, resume, setContextClassLoader, setDaemon, setDefaultUncaughtExceptionHandler, setName, setPriority, setUncaughtExceptionHandler, sleep, sleep, stop, suspend, toString, yield
      • Methods inherited from class java.lang.Object

        equals, finalize, getClass, hashCode, notify, notifyAll, wait, wait, wait
    • Method Detail

      • setStateListener

        public void setStateListener​(StreamThread.StateListener listener)
        Set the StreamThread.StateListener to be notified when state changes. Note this API is internal to Kafka Streams and is not intended to be used by an external application.
      • stillRunning

        public boolean stillRunning()
      • run

        public void run()
        Specified by:
        run in interface java.lang.Runnable
        Overrides:
        run in class java.lang.Thread
      • start

        public void start()
        Overrides:
        start in class java.lang.Thread
      • shutdown

        public void shutdown()
      • consumerMetrics

        public java.util.Map<org.apache.kafka.common.MetricName,​org.apache.kafka.common.Metric> consumerMetrics()