See: Description
Interface | Description |
---|---|
DslStoreSuppliers |
DslStoreSuppliers defines a grouping of factories to construct
stores for each of the types of state store implementations in Kafka
Streams. |
KeyValueBytesStoreSupplier |
A store supplier that can be used to create one or more
KeyValueStore<Bytes, byte[]> instances of type <Bytes, byte[]>. |
KeyValueIterator<K,V> |
Iterator interface of
KeyValue . |
KeyValueStore<K,V> |
A key-value store that supports put/get/delete and range queries.
|
QueryableStoreType<T> |
Used to enable querying of custom
StateStore types via the KafkaStreams API. |
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 more
SessionStore<Byte, byte[]> instances. |
SessionStore<K,AGG> |
Interface for storing the aggregated values of sessions.
|
StoreBuilder<T extends StateStore> |
Build a
StateStore wrapped with optional caching and logging. |
StoreSupplier<T extends StateStore> |
A state store supplier which can create one or more
StateStore instances. |
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.
|
VersionedBytesStore |
A representation of a versioned key-value store as a
KeyValueStore of type <Bytes, byte[]>. |
VersionedBytesStoreSupplier |
A store supplier that can be used to create one or more versioned key-value stores,
specifically,
VersionedBytesStore instances. |
VersionedKeyValueStore<K,V> |
A key-value store that stores multiple record versions per key, and supports timestamp-based
retrieval operations to return the latest record (per key) as of a specified timestamp.
|
VersionedRecordIterator<V> |
Iterator interface of
VersionedRecord . |
WindowBytesStoreSupplier |
A store supplier that can be used to create one or more
WindowStore<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 of
KeyValue with key typed Long used for WindowStore.fetch(Object, long, long)
and WindowStore.fetch(Object, Instant, Instant)
Users must call its close method explicitly upon completeness to release resources,
or use try-with-resources statement (available since JDK7) for this Closeable class. |
Class | Description |
---|---|
BuiltInDslStoreSuppliers |
Collection of builtin
DslStoreSuppliers for Kafka Streams. |
BuiltInDslStoreSuppliers.InMemoryDslStoreSuppliers |
A
DslStoreSuppliers that supplies all stores backed by an in-memory map |
BuiltInDslStoreSuppliers.RocksDBDslStoreSuppliers |
A
DslStoreSuppliers that supplies all stores backed by RocksDB |
DslKeyValueParams |
DslKeyValueParams is a wrapper class for all parameters that function
as inputs to DslStoreSuppliers.keyValueStore(DslKeyValueParams) . |
DslSessionParams |
DslSessionParams is a wrapper class for all parameters that function
as inputs to DslStoreSuppliers.sessionStore(DslSessionParams) . |
DslWindowParams |
DslWindowParams is a wrapper class for all parameters that function
as inputs to DslStoreSuppliers.windowStore(DslWindowParams) . |
HostInfo |
Represents a user defined endpoint in a
KafkaStreams application. |
QueryableStoreTypes |
Provides access to the
QueryableStoreType s provided with KafkaStreams . |
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 | Deprecated
since 3.0.0 use
StreamsMetadata |
ValueAndTimestamp<V> |
Combines a value from a
KeyValue with a timestamp. |
VersionedRecord<V> |
Combines a value (from a key-value record) with a timestamp, for use as the return type
from
VersionedKeyValueStore.get(Object, long) and related methods. |