Class CompositeRestoreListener

    • Field Summary

      Fields 
      Modifier and Type Field Description
      static org.apache.kafka.streams.processor.internals.CompositeRestoreListener.NoOpStateRestoreListener NO_OP_STATE_RESTORE_LISTENER  
    • Method Summary

      All Methods Instance Methods Concrete Methods 
      Modifier and Type Method Description
      void onBatchRestored​(org.apache.kafka.common.TopicPartition topicPartition, java.lang.String storeName, long batchEndOffset, long numRestored)
      Method called after restoring a batch of records.
      void onRestoreEnd​(org.apache.kafka.common.TopicPartition topicPartition, java.lang.String storeName, long totalRestored)
      Method called when restoring the StateStore is complete.
      void onRestoreStart​(org.apache.kafka.common.TopicPartition topicPartition, java.lang.String storeName, long startingOffset, long endingOffset)
      Method called at the very beginning of StateStore restoration.
      void restore​(byte[] key, byte[] value)  
      void restoreAll​(java.util.Collection<KeyValue<byte[],​byte[]>> records)
      Called to restore a number of records.
      void restoreBatch​(java.util.Collection<org.apache.kafka.clients.consumer.ConsumerRecord<byte[],​byte[]>> records)  
      • Methods inherited from class java.lang.Object

        clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
    • Field Detail

      • NO_OP_STATE_RESTORE_LISTENER

        public static final org.apache.kafka.streams.processor.internals.CompositeRestoreListener.NoOpStateRestoreListener NO_OP_STATE_RESTORE_LISTENER