Package org.apache.kafka.streams.state
- 
Interface Summary Interface Description KeyValueBytesStoreSupplier A store supplier that can be used to create one or moreKeyValueStore<Bytes, byte[]>instances of type <Bytes, byte[]>.KeyValueIterator<K,V> Iterator interface ofKeyValue.KeyValueStore<K,V> A key-value store that supports put/get/delete and range queries.QueryableStoreType<T> Used to enable querying of customStateStoretypes via theKafkaStreamsAPI.ReadOnlyKeyValueStore<K,V> A key-value store that only supports read operations.ReadOnlySessionStore<K,AGG> A session store that only supports read operations.ReadOnlyWindowStore<K,V> A window store that only supports read operations.RocksDBConfigSetter An interface to that allows developers to customize the RocksDB settings for a given Store.SessionBytesStoreSupplier A store supplier that can be used to create one or moreSessionStore<Byte, byte[]>instances.SessionStore<K,AGG> Interface for storing the aggregated values of sessions.StoreBuilder<T extends StateStore> Build aStateStorewrapped with optional caching and logging.StoreSupplier<T extends StateStore> A state store supplier which can create one or moreStateStoreinstances.TimestampedBytesStore TimestampedKeyValueStore<K,V> A key-(value/timestamp) store that supports put/get/delete and range queries.TimestampedWindowStore<K,V> Interface for storing the aggregated values of fixed-size time windows.WindowBytesStoreSupplier A store supplier that can be used to create one or moreWindowStore<Byte, byte[]>instances of type <Byte, byte[]>.WindowStore<K,V> Interface for storing the aggregated values of fixed-size time windows.WindowStoreIterator<V> Iterator interface ofKeyValuewith key typedLongused forWindowStore.fetch(Object, long, long)andWindowStore.fetch(Object, Instant, Instant)Users must call itsclosemethod explicitly upon completeness to release resources, or use try-with-resources statement (available since JDK7) for thisCloseableclass. - 
Class Summary Class Description HostInfo Represents a user defined endpoint in aKafkaStreamsapplication.QueryableStoreTypes Provides access to theQueryableStoreTypes provided withKafkaStreams.QueryableStoreTypes.KeyValueStoreType<K,V> QueryableStoreTypes.SessionStoreType<K,V> QueryableStoreTypes.WindowStoreType<K,V> StateSerdes<K,V> Factory for creating serializers / deserializers for state stores in Kafka Streams.Stores Factory for creating state stores in Kafka Streams.StreamsMetadata Represents the state of an instance (process) in aKafkaStreamsapplication.ValueAndTimestamp<V> Combines a value from aKeyValuewith a timestamp.