- AbstractProcessor<K,V> - Class in org.apache.kafka.streams.processor
-
- AbstractProcessor() - Constructor for class org.apache.kafka.streams.processor.AbstractProcessor
-
Deprecated.
- ACCEPTABLE_RECOVERY_LAG_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
acceptable.recovery.lag
- accepts(StateStore) - Method in interface org.apache.kafka.streams.state.QueryableStoreType
-
Called when searching for
StateStore
s to see if they
match the type expected by implementors of this interface.
- activeHost() - Method in class org.apache.kafka.streams.KeyQueryMetadata
-
Get the active Kafka Streams instance for given key.
- activeTasks() - Method in class org.apache.kafka.streams.processor.ThreadMetadata
-
Deprecated.
- activeTasks() - Method in interface org.apache.kafka.streams.ThreadMetadata
-
Metadata of the active tasks assigned to the stream thread.
- addGlobalStore(StoreBuilder<?>, String, Consumed<K, V>, ProcessorSupplier<K, V>) - Method in class org.apache.kafka.streams.StreamsBuilder
-
- addGlobalStore(StoreBuilder<?>, String, Consumed<KIn, VIn>, ProcessorSupplier<KIn, VIn, Void, Void>) - Method in class org.apache.kafka.streams.StreamsBuilder
-
- addGlobalStore(StoreBuilder<?>, String, Deserializer<K>, Deserializer<V>, String, String, ProcessorSupplier<K, V>) - Method in class org.apache.kafka.streams.Topology
-
- addGlobalStore(StoreBuilder<?>, String, TimestampExtractor, Deserializer<K>, Deserializer<V>, String, String, ProcessorSupplier<K, V>) - Method in class org.apache.kafka.streams.Topology
-
- addGlobalStore(StoreBuilder<?>, String, Deserializer<KIn>, Deserializer<VIn>, String, String, ProcessorSupplier<KIn, VIn, Void, Void>) - Method in class org.apache.kafka.streams.Topology
-
- addGlobalStore(StoreBuilder<?>, String, TimestampExtractor, Deserializer<KIn>, Deserializer<VIn>, String, String, ProcessorSupplier<KIn, VIn, Void, Void>) - Method in class org.apache.kafka.streams.Topology
-
- addLatencyRateTotalSensor(String, String, String, Sensor.RecordingLevel, String...) - Method in interface org.apache.kafka.streams.StreamsMetrics
-
Add a latency, rate and total sensor for a specific operation, which will include the following metrics:
average latency
max latency
invocation rate (num.operations / seconds)
total invocation count
Whenever a user records this sensor via Sensor.record(double)
etc, it will be counted as one invocation
of the operation, and hence the rate / count metrics will be updated accordingly; and the recorded latency value
will be used to update the average / max latency as well.
- addProcessor(String, ProcessorSupplier, String...) - Method in class org.apache.kafka.streams.Topology
-
- addProcessor(String, ProcessorSupplier<KIn, VIn, KOut, VOut>, String...) - Method in class org.apache.kafka.streams.Topology
-
Add a new processor node that receives and processes records output by one or more parent source or processor
node.
- addRateTotalSensor(String, String, String, Sensor.RecordingLevel, String...) - Method in interface org.apache.kafka.streams.StreamsMetrics
-
Add a rate and a total sensor for a specific operation, which will include the following metrics:
invocation rate (num.operations / time unit)
total invocation count
Whenever a user records this sensor via Sensor.record(double)
etc,
it will be counted as one invocation of the operation, and hence the rate / count metrics will be updated accordingly.
- addSensor(String, Sensor.RecordingLevel) - Method in interface org.apache.kafka.streams.StreamsMetrics
-
Generic method to create a sensor.
- addSensor(String, Sensor.RecordingLevel, Sensor...) - Method in interface org.apache.kafka.streams.StreamsMetrics
-
Generic method to create a sensor with parent sensors.
- addSink(String, String, String...) - Method in class org.apache.kafka.streams.Topology
-
Add a new sink that forwards records from upstream parent processor and/or source nodes to the named Kafka topic.
- addSink(String, String, StreamPartitioner<? super K, ? super V>, String...) - Method in class org.apache.kafka.streams.Topology
-
Add a new sink that forwards records from upstream parent processor and/or source nodes to the named Kafka topic,
using the supplied partitioner.
- addSink(String, String, Serializer<K>, Serializer<V>, String...) - Method in class org.apache.kafka.streams.Topology
-
Add a new sink that forwards records from upstream parent processor and/or source nodes to the named Kafka topic.
- addSink(String, String, Serializer<K>, Serializer<V>, StreamPartitioner<? super K, ? super V>, String...) - Method in class org.apache.kafka.streams.Topology
-
Add a new sink that forwards records from upstream parent processor and/or source nodes to the named Kafka topic.
- addSink(String, TopicNameExtractor<K, V>, String...) - Method in class org.apache.kafka.streams.Topology
-
Add a new sink that forwards records from upstream parent processor and/or source nodes to Kafka topics based on topicExtractor
.
- addSink(String, TopicNameExtractor<K, V>, StreamPartitioner<? super K, ? super V>, String...) - Method in class org.apache.kafka.streams.Topology
-
Add a new sink that forwards records from upstream parent processor and/or source nodes to Kafka topics based on topicExtractor
,
using the supplied partitioner.
- addSink(String, TopicNameExtractor<K, V>, Serializer<K>, Serializer<V>, String...) - Method in class org.apache.kafka.streams.Topology
-
Add a new sink that forwards records from upstream parent processor and/or source nodes to Kafka topics based on topicExtractor
.
- addSink(String, TopicNameExtractor<K, V>, Serializer<K>, Serializer<V>, StreamPartitioner<? super K, ? super V>, String...) - Method in class org.apache.kafka.streams.Topology
-
Add a new sink that forwards records from upstream parent processor and/or source nodes to Kafka topics based on topicExtractor
.
- addSource(String, String...) - Method in class org.apache.kafka.streams.Topology
-
Add a new source that consumes the named topics and forward the records to child processor and/or sink nodes.
- addSource(String, Pattern) - Method in class org.apache.kafka.streams.Topology
-
Add a new source that consumes from topics matching the given pattern
and forward the records to child processor and/or sink nodes.
- addSource(Topology.AutoOffsetReset, String, String...) - Method in class org.apache.kafka.streams.Topology
-
Add a new source that consumes the named topics and forward the records to child processor and/or sink nodes.
- addSource(Topology.AutoOffsetReset, String, Pattern) - Method in class org.apache.kafka.streams.Topology
-
Add a new source that consumes from topics matching the given pattern
and forward the records to child processor and/or sink nodes.
- addSource(TimestampExtractor, String, String...) - Method in class org.apache.kafka.streams.Topology
-
Add a new source that consumes the named topics and forward the records to child processor and/or sink nodes.
- addSource(TimestampExtractor, String, Pattern) - Method in class org.apache.kafka.streams.Topology
-
Add a new source that consumes from topics matching the given pattern
and forward the records to child processor and/or sink nodes.
- addSource(Topology.AutoOffsetReset, TimestampExtractor, String, String...) - Method in class org.apache.kafka.streams.Topology
-
Add a new source that consumes the named topics and forward the records to child processor and/or sink nodes.
- addSource(Topology.AutoOffsetReset, TimestampExtractor, String, Pattern) - Method in class org.apache.kafka.streams.Topology
-
Add a new source that consumes from topics matching the given pattern and forward the records to child processor
and/or sink nodes.
- addSource(String, Deserializer<?>, Deserializer<?>, String...) - Method in class org.apache.kafka.streams.Topology
-
Add a new source that consumes the named topics and forwards the records to child processor and/or sink nodes.
- addSource(String, Deserializer<?>, Deserializer<?>, Pattern) - Method in class org.apache.kafka.streams.Topology
-
Add a new source that consumes from topics matching the given pattern and forwards the records to child processor
and/or sink nodes.
- addSource(Topology.AutoOffsetReset, String, Deserializer<?>, Deserializer<?>, String...) - Method in class org.apache.kafka.streams.Topology
-
Add a new source that consumes from topics matching the given pattern and forwards the records to child processor
and/or sink nodes.
- addSource(Topology.AutoOffsetReset, String, Deserializer<?>, Deserializer<?>, Pattern) - Method in class org.apache.kafka.streams.Topology
-
Add a new source that consumes from topics matching the given pattern and forwards the records to child processor
and/or sink nodes.
- addSource(Topology.AutoOffsetReset, String, TimestampExtractor, Deserializer<?>, Deserializer<?>, String...) - Method in class org.apache.kafka.streams.Topology
-
Add a new source that consumes the named topics and forwards the records to child processor and/or sink nodes.
- addSource(Topology.AutoOffsetReset, String, TimestampExtractor, Deserializer<?>, Deserializer<?>, Pattern) - Method in class org.apache.kafka.streams.Topology
-
Add a new source that consumes from topics matching the given pattern and forwards the records to child processor
and/or sink nodes.
- addStateStore(StoreBuilder<?>) - Method in class org.apache.kafka.streams.StreamsBuilder
-
Adds a state store to the underlying
Topology
.
- addStateStore(StoreBuilder<?>, String...) - Method in class org.apache.kafka.streams.Topology
-
Adds a state store.
- addStreamThread() - Method in class org.apache.kafka.streams.KafkaStreams
-
Adds and starts a stream thread in addition to the stream threads that are already running in this
Kafka Streams client.
- ADMIN_CLIENT_PREFIX - Static variable in class org.apache.kafka.streams.StreamsConfig
-
Prefix used to isolate admin
configs from other client configs.
- adminClientId() - Method in class org.apache.kafka.streams.processor.ThreadMetadata
-
Deprecated.
- adminClientId() - Method in interface org.apache.kafka.streams.ThreadMetadata
-
Client ID of the admin client used by the stream thread.
- adminClientPrefix(String) - Static method in class org.apache.kafka.streams.StreamsConfig
-
- advanceBy(Duration) - Method in class org.apache.kafka.streams.kstream.TimeWindows
-
Return a window definition with the original size, but advance ("hop") the window by the given interval, which
specifies by how much a window moves forward relative to the previous one.
- advanceMs - Variable in class org.apache.kafka.streams.kstream.TimeWindows
-
The size of the window's advance interval in milliseconds, i.e., by how much a window moves forward relative to
the previous one.
- after(Duration) - Method in class org.apache.kafka.streams.kstream.JoinWindows
-
Changes the end window boundary to timeDifference
but keep the start window boundary as is.
- afterMs - Variable in class org.apache.kafka.streams.kstream.JoinWindows
-
Maximum time difference for tuples that are after the join tuple.
- aggregate(Initializer<VOut>) - Method in interface org.apache.kafka.streams.kstream.CogroupedKStream
-
Aggregate the values of records in these streams by the grouped key.
- aggregate(Initializer<VOut>, Named) - Method in interface org.apache.kafka.streams.kstream.CogroupedKStream
-
Aggregate the values of records in these streams by the grouped key.
- aggregate(Initializer<VOut>, Materialized<K, VOut, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.CogroupedKStream
-
Aggregate the values of records in these streams by the grouped key.
- aggregate(Initializer<VOut>, Named, Materialized<K, VOut, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.CogroupedKStream
-
Aggregate the values of records in these streams by the grouped key.
- aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>) - Method in interface org.apache.kafka.streams.kstream.KGroupedStream
-
Aggregate the values of records in this stream by the grouped key.
- aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KGroupedStream
-
Aggregate the values of records in this stream by the grouped key.
- aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, Named, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KGroupedStream
-
Aggregate the values of records in this stream by the grouped key.
- aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, Aggregator<? super K, ? super V, VR>, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KGroupedTable
-
Aggregate the value of records of the original
KTable
that got
mapped
to the same key into a new instance of
KTable
.
- aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, Aggregator<? super K, ? super V, VR>, Named, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KGroupedTable
-
Aggregate the value of records of the original
KTable
that got
mapped
to the same key into a new instance of
KTable
.
- aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, Aggregator<? super K, ? super V, VR>) - Method in interface org.apache.kafka.streams.kstream.KGroupedTable
-
Aggregate the value of records of the original
KTable
that got
mapped
to the same key into a new instance of
KTable
using default serializers and deserializers.
- aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, Aggregator<? super K, ? super V, VR>, Named) - Method in interface org.apache.kafka.streams.kstream.KGroupedTable
-
Aggregate the value of records of the original
KTable
that got
mapped
to the same key into a new instance of
KTable
using default serializers and deserializers.
- aggregate(Initializer<V>, Merger<? super K, V>) - Method in interface org.apache.kafka.streams.kstream.SessionWindowedCogroupedKStream
-
Aggregate the values of records in these streams by the grouped key and defined sessions.
- aggregate(Initializer<V>, Merger<? super K, V>, Named) - Method in interface org.apache.kafka.streams.kstream.SessionWindowedCogroupedKStream
-
Aggregate the values of records in these streams by the grouped key and defined sessions.
- aggregate(Initializer<V>, Merger<? super K, V>, Materialized<K, V, SessionStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.SessionWindowedCogroupedKStream
-
Aggregate the values of records in these streams by the grouped key and defined sessions.
- aggregate(Initializer<V>, Merger<? super K, V>, Named, Materialized<K, V, SessionStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.SessionWindowedCogroupedKStream
-
Aggregate the values of records in these streams by the grouped key and defined sessions.
- aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, Merger<? super K, VR>) - Method in interface org.apache.kafka.streams.kstream.SessionWindowedKStream
-
Aggregate the values of records in this stream by the grouped key and defined sessions.
- aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, Merger<? super K, VR>, Named) - Method in interface org.apache.kafka.streams.kstream.SessionWindowedKStream
-
Aggregate the values of records in this stream by the grouped key and defined sessions.
- aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, Merger<? super K, VR>, Materialized<K, VR, SessionStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.SessionWindowedKStream
-
Aggregate the values of records in this stream by the grouped key and defined sessions.
- aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, Merger<? super K, VR>, Named, Materialized<K, VR, SessionStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.SessionWindowedKStream
-
Aggregate the values of records in this stream by the grouped key and defined sessions.
- aggregate(Initializer<V>) - Method in interface org.apache.kafka.streams.kstream.TimeWindowedCogroupedKStream
-
Aggregate the values of records in this stream by the grouped key and defined windows.
- aggregate(Initializer<V>, Named) - Method in interface org.apache.kafka.streams.kstream.TimeWindowedCogroupedKStream
-
Aggregate the values of records in this stream by the grouped key and defined windows.
- aggregate(Initializer<V>, Materialized<K, V, WindowStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.TimeWindowedCogroupedKStream
-
Aggregate the values of records in this stream by the grouped key and defined windows.
- aggregate(Initializer<V>, Named, Materialized<K, V, WindowStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.TimeWindowedCogroupedKStream
-
Aggregate the values of records in this stream by the grouped key and defined windows.
- aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>) - Method in interface org.apache.kafka.streams.kstream.TimeWindowedKStream
-
Aggregate the values of records in this stream by the grouped key and defined windows.
- aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, Named) - Method in interface org.apache.kafka.streams.kstream.TimeWindowedKStream
-
Aggregate the values of records in this stream by the grouped key and defined windows.
- aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, Materialized<K, VR, WindowStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.TimeWindowedKStream
-
Aggregate the values of records in this stream by the grouped key and defined windows.
- aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, Named, Materialized<K, VR, WindowStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.TimeWindowedKStream
-
Aggregate the values of records in this stream by the grouped key and defined windows.
- Aggregator<K,V,VA> - Interface in org.apache.kafka.streams.kstream
-
The Aggregator
interface for aggregating values of the given key.
- all() - Static method in class org.apache.kafka.streams.processor.To
-
Forward the key/value pair to all downstream processors
- all() - Method in interface org.apache.kafka.streams.state.ReadOnlyKeyValueStore
-
Return an iterator over all keys in this store.
- all() - Method in interface org.apache.kafka.streams.state.ReadOnlyWindowStore
-
Gets all the key-value pairs in the existing windows.
- allLocalStorePartitionLags() - Method in class org.apache.kafka.streams.KafkaStreams
-
Returns
LagInfo
, for all store partitions (active or standby) local to this Streams instance.
- allMetadata() - Method in class org.apache.kafka.streams.KafkaStreams
-
- allMetadataForStore(String) - Method in class org.apache.kafka.streams.KafkaStreams
-
- appConfigs() - Method in interface org.apache.kafka.streams.processor.api.ProcessorContext
-
Returns all the application config properties as key/value pairs.
- appConfigs() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
-
Return all the application config properties as key/value pairs.
- appConfigs() - Method in interface org.apache.kafka.streams.processor.StateStoreContext
-
Returns all the application config properties as key/value pairs.
- appConfigsWithPrefix(String) - Method in interface org.apache.kafka.streams.processor.api.ProcessorContext
-
Return all the application config properties with the given key prefix, as key/value pairs
stripping the prefix.
- appConfigsWithPrefix(String) - Method in interface org.apache.kafka.streams.processor.ProcessorContext
-
Return all the application config properties with the given key prefix, as key/value pairs
stripping the prefix.
- appConfigsWithPrefix(String) - Method in interface org.apache.kafka.streams.processor.StateStoreContext
-
Returns all the application config properties with the given key prefix, as key/value pairs
stripping the prefix.
- APPLICATION_ID_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
application.id
- APPLICATION_SERVER_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
application.server
- applicationId() - Method in interface org.apache.kafka.streams.processor.api.ProcessorContext
-
Return the application id.
- applicationId() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
-
Return the application id.
- applicationId() - Method in interface org.apache.kafka.streams.processor.StateStoreContext
-
Returns the application id.
- apply(K, V, VA) - Method in interface org.apache.kafka.streams.kstream.Aggregator
-
Compute a new aggregate from the key and value of a record and the current aggregate of the same key.
- apply(K, V) - Method in interface org.apache.kafka.streams.kstream.ForeachAction
-
Perform an action for each record of a stream.
- apply() - Method in interface org.apache.kafka.streams.kstream.Initializer
-
Return the initial value for an aggregation.
- apply(K, V) - Method in interface org.apache.kafka.streams.kstream.KeyValueMapper
-
Map a record with the given key and value to a new value.
- apply(K, V, V) - Method in interface org.apache.kafka.streams.kstream.Merger
-
Compute a new aggregate from the key and two aggregates.
- apply(V, V) - Method in interface org.apache.kafka.streams.kstream.Reducer
-
Aggregate the two given values into a single one.
- apply(V1, V2) - Method in interface org.apache.kafka.streams.kstream.ValueJoiner
-
Return a joined value consisting of value1
and value2
.
- apply(K1, V1, V2) - Method in interface org.apache.kafka.streams.kstream.ValueJoinerWithKey
-
Return a joined value consisting of readOnlyKey
, value1
and value2
.
- apply(V) - Method in interface org.apache.kafka.streams.kstream.ValueMapper
-
Map the given value to a new value.
- apply(K, V) - Method in interface org.apache.kafka.streams.kstream.ValueMapperWithKey
-
Map the given [key and ]value to a new value.
- approximateNumEntries() - Method in interface org.apache.kafka.streams.state.ReadOnlyKeyValueStore
-
Return an approximate count of key-value mappings in this store.
- as(String) - Static method in class org.apache.kafka.streams.kstream.Branched
-
Create an instance of Branched
with provided branch name suffix.
- as(String) - Static method in class org.apache.kafka.streams.kstream.Consumed
-
Create an instance of
Consumed
with provided processor name.
- as(String) - Static method in class org.apache.kafka.streams.kstream.Grouped
-
Create a
Grouped
instance with the provided name used as part of the repartition topic if required.
- as(String) - Static method in class org.apache.kafka.streams.kstream.Joined
-
Create an instance of Joined
with base name for all components of the join, this may
include any repartition topics created to complete the join.
- as(String) - Static method in class org.apache.kafka.streams.kstream.Materialized
-
- as(WindowBytesStoreSupplier) - Static method in class org.apache.kafka.streams.kstream.Materialized
-
- as(SessionBytesStoreSupplier) - Static method in class org.apache.kafka.streams.kstream.Materialized
-
- as(KeyValueBytesStoreSupplier) - Static method in class org.apache.kafka.streams.kstream.Materialized
-
- as(String) - Static method in class org.apache.kafka.streams.kstream.Named
-
Create a Named instance with provided name.
- as(String) - Static method in class org.apache.kafka.streams.kstream.Produced
-
Create an instance of
Produced
with provided processor name.
- as(String) - Static method in class org.apache.kafka.streams.kstream.Repartitioned
-
Create a Repartitioned
instance with the provided name used as part of the repartition topic.
- as(String) - Static method in class org.apache.kafka.streams.kstream.StreamJoined
-
Creates a
StreamJoined
instance using the provided name for the state stores and hence the changelog
topics for the join stores.
- as(String) - Static method in class org.apache.kafka.streams.kstream.TableJoined
-
Create an instance of TableJoined
with base name for all components of the join, including internal topics
created to complete the join.
- ASSIGNMENT_LISTENER - Static variable in class org.apache.kafka.streams.StreamsConfig.InternalConfig
-
- AT_LEAST_ONCE - Static variable in class org.apache.kafka.streams.StreamsConfig
-
- CACHE_MAX_BYTES_BUFFERING_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
cache.max.bytes.buffering
- cachingEnabled - Variable in class org.apache.kafka.streams.kstream.Materialized
-
- cancel() - Method in interface org.apache.kafka.streams.processor.Cancellable
-
Cancel the scheduled operation to avoid future calls.
- Cancellable - Interface in org.apache.kafka.streams.processor
-
- chainConsumer - Variable in class org.apache.kafka.streams.kstream.Branched
-
- chainFunction - Variable in class org.apache.kafka.streams.kstream.Branched
-
- child(String) - Static method in class org.apache.kafka.streams.processor.To
-
Forward the key/value pair to one of the downstream processors designated by the downstream processor name.
- childName - Variable in class org.apache.kafka.streams.processor.To
-
- cleanUp() - Method in class org.apache.kafka.streams.KafkaStreams
-
- CLIENT_ID_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
client.id
- close() - Method in class org.apache.kafka.streams.KafkaStreams
-
Shutdown this KafkaStreams
instance by signaling all the threads to stop, and then wait for them to join.
- close(Duration) - Method in class org.apache.kafka.streams.KafkaStreams
-
Shutdown this KafkaStreams
by signaling all the threads to stop, and then wait up to the timeout for the
threads to join.
- close() - Method in class org.apache.kafka.streams.kstream.SessionWindowedDeserializer
-
- close() - Method in class org.apache.kafka.streams.kstream.SessionWindowedSerializer
-
- close() - Method in class org.apache.kafka.streams.kstream.TimeWindowedDeserializer
-
- close() - Method in class org.apache.kafka.streams.kstream.TimeWindowedSerializer
-
- close() - Method in interface org.apache.kafka.streams.kstream.Transformer
-
Close this transformer and clean up any resources.
- close() - Method in interface org.apache.kafka.streams.kstream.ValueTransformer
-
Close this transformer and clean up any resources.
- close() - Method in interface org.apache.kafka.streams.kstream.ValueTransformerWithKey
-
Close this processor and clean up any resources.
- close() - Method in class org.apache.kafka.streams.processor.AbstractProcessor
-
Deprecated.
Close this processor and clean up any resources.
- close() - Method in interface org.apache.kafka.streams.processor.api.Processor
-
Close this processor and clean up any resources.
- close() - Method in interface org.apache.kafka.streams.processor.Processor
-
Deprecated.
Close this processor and clean up any resources.
- close() - Method in interface org.apache.kafka.streams.processor.StateStore
-
Close the storage engine.
- close() - Method in interface org.apache.kafka.streams.state.KeyValueIterator
-
- close(String, Options) - Method in interface org.apache.kafka.streams.state.RocksDBConfigSetter
-
Close any user-constructed objects that inherit from org.rocksdb.RocksObject
.
- close() - Method in interface org.apache.kafka.streams.state.WindowStoreIterator
-
- cogroup(KGroupedStream<K, VIn>, Aggregator<? super K, ? super VIn, VOut>) - Method in interface org.apache.kafka.streams.kstream.CogroupedKStream
-
- cogroup(Aggregator<? super K, ? super V, VOut>) - Method in interface org.apache.kafka.streams.kstream.KGroupedStream
-
Create a new
CogroupedKStream
from the this grouped KStream to allow cogrouping other
KGroupedStream
to it.
- CogroupedKStream<K,VOut> - Interface in org.apache.kafka.streams.kstream
-
CogroupedKStream
is an abstraction of multiple
grouped record streams of
KeyValue
pairs.
- commit() - Method in interface org.apache.kafka.streams.processor.api.ProcessorContext
-
Request a commit.
- commit() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
-
Request a commit.
- COMMIT_INTERVAL_MS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
commit.interval.ms
- committedOffsets() - Method in class org.apache.kafka.streams.processor.TaskMetadata
-
Deprecated.
This function will return a map of TopicPartitions and the highest committed offset seen so far
- committedOffsets() - Method in interface org.apache.kafka.streams.TaskMetadata
-
Offsets of the source topic partitions committed so far by the task.
- compareTo(TaskId) - Method in class org.apache.kafka.streams.processor.TaskId
-
- configDef() - Static method in class org.apache.kafka.streams.StreamsConfig
-
Return a copy of the config definition.
- configure(Map<String, ?>) - Method in class org.apache.kafka.streams.errors.DefaultProductionExceptionHandler
-
- configure(Map<String, ?>) - Method in class org.apache.kafka.streams.errors.LogAndContinueExceptionHandler
-
- configure(Map<String, ?>) - Method in class org.apache.kafka.streams.errors.LogAndFailExceptionHandler
-
- configure(Map<String, ?>, boolean) - Method in class org.apache.kafka.streams.kstream.SessionWindowedDeserializer
-
- configure(Map<String, ?>, boolean) - Method in class org.apache.kafka.streams.kstream.SessionWindowedSerializer
-
- configure(Map<String, ?>, boolean) - Method in class org.apache.kafka.streams.kstream.TimeWindowedDeserializer
-
- configure(Map<String, ?>, boolean) - Method in class org.apache.kafka.streams.kstream.TimeWindowedSerializer
-
- ConnectedStoreProvider - Interface in org.apache.kafka.streams.processor
-
Provides a set of
StoreBuilder
s that will be automatically added to the topology and connected to the
associated processor.
- CONNECTIONS_MAX_IDLE_MS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
connections.max.idle.ms
- connectProcessorAndStateStores(String, String...) - Method in class org.apache.kafka.streams.Topology
-
Connects the processor and the state stores.
- Consumed<K,V> - Class in org.apache.kafka.streams.kstream
-
- Consumed(Consumed<K, V>) - Constructor for class org.apache.kafka.streams.kstream.Consumed
-
Create an instance of
Consumed
from an existing instance.
- CONSUMER_PREFIX - Static variable in class org.apache.kafka.streams.StreamsConfig
-
Prefix used to isolate consumer
configs from other client configs.
- consumerClientId() - Method in class org.apache.kafka.streams.processor.ThreadMetadata
-
Deprecated.
- consumerClientId() - Method in interface org.apache.kafka.streams.ThreadMetadata
-
Client ID of the Kafka consumer used by the stream thread.
- consumerPrefix(String) - Static method in class org.apache.kafka.streams.StreamsConfig
-
- context - Variable in class org.apache.kafka.streams.processor.AbstractProcessor
-
Deprecated.
- context() - Method in class org.apache.kafka.streams.processor.AbstractProcessor
-
Deprecated.
- context() - Method in class org.apache.kafka.streams.processor.api.ContextualProcessor
-
- ContextualProcessor<KIn,VIn,KOut,VOut> - Class in org.apache.kafka.streams.processor.api
-
- ContextualProcessor() - Constructor for class org.apache.kafka.streams.processor.api.ContextualProcessor
-
- convertToTimestampedFormat(byte[]) - Static method in interface org.apache.kafka.streams.state.TimestampedBytesStore
-
- corruptedTasks() - Method in exception org.apache.kafka.streams.errors.TaskCorruptedException
-
- count() - Method in interface org.apache.kafka.streams.kstream.KGroupedStream
-
Count the number of records in this stream by the grouped key.
- count(Named) - Method in interface org.apache.kafka.streams.kstream.KGroupedStream
-
Count the number of records in this stream by the grouped key.
- count(Materialized<K, Long, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KGroupedStream
-
Count the number of records in this stream by the grouped key.
- count(Named, Materialized<K, Long, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KGroupedStream
-
Count the number of records in this stream by the grouped key.
- count(Materialized<K, Long, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KGroupedTable
-
Count number of records of the original
KTable
that got
mapped
to
the same key into a new instance of
KTable
.
- count(Named, Materialized<K, Long, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KGroupedTable
-
Count number of records of the original
KTable
that got
mapped
to
the same key into a new instance of
KTable
.
- count() - Method in interface org.apache.kafka.streams.kstream.KGroupedTable
-
Count number of records of the original
KTable
that got
mapped
to
the same key into a new instance of
KTable
.
- count(Named) - Method in interface org.apache.kafka.streams.kstream.KGroupedTable
-
Count number of records of the original
KTable
that got
mapped
to
the same key into a new instance of
KTable
.
- count() - Method in interface org.apache.kafka.streams.kstream.SessionWindowedKStream
-
Count the number of records in this stream by the grouped key and defined sessions.
- count(Named) - Method in interface org.apache.kafka.streams.kstream.SessionWindowedKStream
-
Count the number of records in this stream by the grouped key and defined sessions.
- count(Materialized<K, Long, SessionStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.SessionWindowedKStream
-
Count the number of records in this stream by the grouped key and defined sessions.
- count(Named, Materialized<K, Long, SessionStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.SessionWindowedKStream
-
Count the number of records in this stream by the grouped key and defined sessions.
- count() - Method in interface org.apache.kafka.streams.kstream.TimeWindowedKStream
-
Count the number of records in this stream by the grouped key and defined windows.
- count(Named) - Method in interface org.apache.kafka.streams.kstream.TimeWindowedKStream
-
Count the number of records in this stream by the grouped key and defined windows.
- count(Materialized<K, Long, WindowStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.TimeWindowedKStream
-
Count the number of records in this stream by the grouped key and defined windows.
- count(Named, Materialized<K, Long, WindowStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.TimeWindowedKStream
-
Count the number of records in this stream by the grouped key and defined windows.
- create(StateStoreProvider, String) - Method in interface org.apache.kafka.streams.state.QueryableStoreType
-
Create an instance of
T
(usually a facade) that developers can use
to query the underlying
StateStore
s.
- create(StateStoreProvider, String) - Method in class org.apache.kafka.streams.state.QueryableStoreTypes.KeyValueStoreType
-
- create(StateStoreProvider, String) - Method in class org.apache.kafka.streams.state.QueryableStoreTypes.SessionStoreType
-
- create(StateStoreProvider, String) - Method in class org.apache.kafka.streams.state.QueryableStoreTypes.WindowStoreType
-
- currentOffsetPosition() - Method in class org.apache.kafka.streams.LagInfo
-
Get the current maximum offset on the store partition's changelog topic, that has been successfully written into
the store partition's state store.
- currentStreamTimeMs() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
-
Return the current stream-time in milliseconds.
- currentSystemTimeMs() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
-
Return the current system timestamp (also called wall-clock time) in milliseconds.
- FailOnInvalidTimestamp - Class in org.apache.kafka.streams.processor
-
Retrieves embedded metadata timestamps from Kafka messages.
- FailOnInvalidTimestamp() - Constructor for class org.apache.kafka.streams.processor.FailOnInvalidTimestamp
-
- fetch(K) - Method in interface org.apache.kafka.streams.state.ReadOnlySessionStore
-
Retrieve all aggregated sessions for the provided key.
- fetch(K, K) - Method in interface org.apache.kafka.streams.state.ReadOnlySessionStore
-
Retrieve all aggregated sessions for the given range of keys.
- fetch(K, long) - Method in interface org.apache.kafka.streams.state.ReadOnlyWindowStore
-
Get the value of key from a window.
- fetch(K, Instant, Instant) - Method in interface org.apache.kafka.streams.state.ReadOnlyWindowStore
-
Get all the key-value pairs with the given key and the time range from all the existing windows.
- fetch(K, K, Instant, Instant) - Method in interface org.apache.kafka.streams.state.ReadOnlyWindowStore
-
Get all the key-value pairs in the given key range and time range from all the existing windows.
- fetch(K, long, long) - Method in interface org.apache.kafka.streams.state.WindowStore
-
Get all the key-value pairs with the given key and the time range from all the existing windows.
- fetch(K, Instant, Instant) - Method in interface org.apache.kafka.streams.state.WindowStore
-
- fetch(K, K, long, long) - Method in interface org.apache.kafka.streams.state.WindowStore
-
Get all the key-value pairs in the given key range and time range from all the existing windows.
- fetch(K, K, Instant, Instant) - Method in interface org.apache.kafka.streams.state.WindowStore
-
- fetchAll(Instant, Instant) - Method in interface org.apache.kafka.streams.state.ReadOnlyWindowStore
-
Gets all the key-value pairs that belong to the windows within in the given time range.
- fetchAll(long, long) - Method in interface org.apache.kafka.streams.state.WindowStore
-
Gets all the key-value pairs that belong to the windows within in the given time range.
- fetchAll(Instant, Instant) - Method in interface org.apache.kafka.streams.state.WindowStore
-
- fetchSession(K, long, long) - Method in interface org.apache.kafka.streams.state.ReadOnlySessionStore
-
Get the value of key from a single session.
- fetchSession(K, Instant, Instant) - Method in interface org.apache.kafka.streams.state.ReadOnlySessionStore
-
Get the value of key from a single session.
- fetchSession(K, Instant, Instant) - Method in interface org.apache.kafka.streams.state.SessionStore
-
- filter(Predicate<? super K, ? super V>) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Create a new KStream
that consists of all records of this stream which satisfy the given predicate.
- filter(Predicate<? super K, ? super V>, Named) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Create a new KStream
that consists of all records of this stream which satisfy the given predicate.
- filter(Predicate<? super K, ? super V>) - Method in interface org.apache.kafka.streams.kstream.KTable
-
Create a new KTable
that consists of all records of this KTable
which satisfy the given
predicate, with default serializers, deserializers, and state store.
- filter(Predicate<? super K, ? super V>, Named) - Method in interface org.apache.kafka.streams.kstream.KTable
-
Create a new KTable
that consists of all records of this KTable
which satisfy the given
predicate, with default serializers, deserializers, and state store.
- filter(Predicate<? super K, ? super V>, Materialized<K, V, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KTable
-
Create a new
KTable
that consists of all records of this
KTable
which satisfy the given
predicate, with the
key serde
,
value serde
, and the underlying
materialized state storage
configured in the
Materialized
instance.
- filter(Predicate<? super K, ? super V>, Named, Materialized<K, V, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KTable
-
Create a new
KTable
that consists of all records of this
KTable
which satisfy the given
predicate, with the
key serde
,
value serde
, and the underlying
materialized state storage
configured in the
Materialized
instance.
- filterNot(Predicate<? super K, ? super V>) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Create a new KStream
that consists all records of this stream which do not satisfy the given
predicate.
- filterNot(Predicate<? super K, ? super V>, Named) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Create a new KStream
that consists all records of this stream which do not satisfy the given
predicate.
- filterNot(Predicate<? super K, ? super V>) - Method in interface org.apache.kafka.streams.kstream.KTable
-
Create a new KTable
that consists all records of this KTable
which do not satisfy the
given predicate, with default serializers, deserializers, and state store.
- filterNot(Predicate<? super K, ? super V>, Named) - Method in interface org.apache.kafka.streams.kstream.KTable
-
Create a new KTable
that consists all records of this KTable
which do not satisfy the
given predicate, with default serializers, deserializers, and state store.
- filterNot(Predicate<? super K, ? super V>, Materialized<K, V, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KTable
-
Create a new
KTable
that consists all records of this
KTable
which do
not satisfy the
given predicate, with the
key serde
,
value serde
, and the underlying
materialized state storage
configured in the
Materialized
instance.
- filterNot(Predicate<? super K, ? super V>, Named, Materialized<K, V, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KTable
-
Create a new
KTable
that consists all records of this
KTable
which do
not satisfy the
given predicate, with the
key serde
,
value serde
, and the underlying
materialized state storage
configured in the
Materialized
instance.
- findSessions(K, long, long) - Method in interface org.apache.kafka.streams.state.ReadOnlySessionStore
-
Fetch any sessions with the matching key and the sessions end is ≥ earliestSessionEndTime
and the sessions start is ≤ latestSessionStartTime iterating from earliest to latest.
- findSessions(K, Instant, Instant) - Method in interface org.apache.kafka.streams.state.ReadOnlySessionStore
-
Fetch any sessions with the matching key and the sessions end is ≥ earliestSessionEndTime
and the sessions start is ≤ latestSessionStartTime iterating from earliest to latest.
- findSessions(K, K, long, long) - Method in interface org.apache.kafka.streams.state.ReadOnlySessionStore
-
Fetch any sessions in the given range of keys and the sessions end is ≥
earliestSessionEndTime and the sessions start is ≤ latestSessionStartTime iterating from
earliest to latest.
- findSessions(K, K, Instant, Instant) - Method in interface org.apache.kafka.streams.state.ReadOnlySessionStore
-
Fetch any sessions in the given range of keys and the sessions end is ≥
earliestSessionEndTime and the sessions start is ≤ latestSessionStartTime iterating from
earliest to latest.
- findSessions(K, Instant, Instant) - Method in interface org.apache.kafka.streams.state.SessionStore
-
- findSessions(K, K, Instant, Instant) - Method in interface org.apache.kafka.streams.state.SessionStore
-
- flatMap(KeyValueMapper<? super K, ? super V, ? extends Iterable<? extends KeyValue<? extends KR, ? extends VR>>>) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Transform each record of the input stream into zero or more records in the output stream (both key and value type
can be altered arbitrarily).
- flatMap(KeyValueMapper<? super K, ? super V, ? extends Iterable<? extends KeyValue<? extends KR, ? extends VR>>>, Named) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Transform each record of the input stream into zero or more records in the output stream (both key and value type
can be altered arbitrarily).
- flatMapValues(ValueMapper<? super V, ? extends Iterable<? extends VR>>) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Create a new KStream
by transforming the value of each record in this stream into zero or more values
with the same key in the new stream.
- flatMapValues(ValueMapper<? super V, ? extends Iterable<? extends VR>>, Named) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Create a new KStream
by transforming the value of each record in this stream into zero or more values
with the same key in the new stream.
- flatMapValues(ValueMapperWithKey<? super K, ? super V, ? extends Iterable<? extends VR>>) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Create a new KStream
by transforming the value of each record in this stream into zero or more values
with the same key in the new stream.
- flatMapValues(ValueMapperWithKey<? super K, ? super V, ? extends Iterable<? extends VR>>, Named) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Create a new KStream
by transforming the value of each record in this stream into zero or more values
with the same key in the new stream.
- flatTransform(TransformerSupplier<? super K, ? super V, Iterable<KeyValue<K1, V1>>>, String...) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Transform each record of the input stream into zero or more records in the output stream (both key and value type
can be altered arbitrarily).
- flatTransform(TransformerSupplier<? super K, ? super V, Iterable<KeyValue<K1, V1>>>, Named, String...) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Transform each record of the input stream into zero or more records in the output stream (both key and value type
can be altered arbitrarily).
- flatTransformValues(ValueTransformerSupplier<? super V, Iterable<VR>>, String...) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Transform the value of each input record into zero or more new values (with possibly a new
type) and emit for each new value a record with the same key of the input record and the value.
- flatTransformValues(ValueTransformerSupplier<? super V, Iterable<VR>>, Named, String...) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Transform the value of each input record into zero or more new values (with possibly a new
type) and emit for each new value a record with the same key of the input record and the value.
- flatTransformValues(ValueTransformerWithKeySupplier<? super K, ? super V, Iterable<VR>>, String...) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Transform the value of each input record into zero or more new values (with possibly a new
type) and emit for each new value a record with the same key of the input record and the value.
- flatTransformValues(ValueTransformerWithKeySupplier<? super K, ? super V, Iterable<VR>>, Named, String...) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Transform the value of each input record into zero or more new values (with possibly a new
type) and emit for each new value a record with the same key of the input record and the value.
- flush() - Method in interface org.apache.kafka.streams.processor.StateStore
-
Flush any cached data
- forChangelog(boolean) - Method in class org.apache.kafka.streams.kstream.WindowedSerdes.TimeWindowedSerde
-
- foreach(ForeachAction<? super K, ? super V>) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Perform an action on each record of KStream
.
- foreach(ForeachAction<? super K, ? super V>, Named) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Perform an action on each record of KStream
.
- ForeachAction<K,V> - Interface in org.apache.kafka.streams.kstream
-
The
ForeachAction
interface for performing an action on a
key-value
pair
.
- ForeachProcessor<K,V> - Class in org.apache.kafka.streams.kstream
-
- ForeachProcessor(ForeachAction<K, V>) - Constructor for class org.apache.kafka.streams.kstream.ForeachProcessor
-
- forward(Record<K, V>) - Method in interface org.apache.kafka.streams.processor.api.ProcessorContext
-
Forward a record to all child processors.
- forward(Record<K, V>, String) - Method in interface org.apache.kafka.streams.processor.api.ProcessorContext
-
Forward a record to the specified child processor.
- forward(K, V) - Method in interface org.apache.kafka.streams.processor.ProcessorContext
-
Forward a key/value pair to all downstream processors.
- forward(K, V, To) - Method in interface org.apache.kafka.streams.processor.ProcessorContext
-
Forward a key/value pair to the specified downstream processors.
- fromNameAndType(String, QueryableStoreType<T>) - Static method in class org.apache.kafka.streams.StoreQueryParameters
-
- KafkaClientSupplier - Interface in org.apache.kafka.streams
-
KafkaClientSupplier
can be used to provide custom Kafka clients to a
KafkaStreams
instance.
- KafkaStreams - Class in org.apache.kafka.streams
-
A Kafka client that allows for performing continuous computation on input coming from one or more input topics and
sends output to zero, one, or more output topics.
- KafkaStreams(Topology, Properties) - Constructor for class org.apache.kafka.streams.KafkaStreams
-
Create a KafkaStreams
instance.
- KafkaStreams(Topology, Properties, KafkaClientSupplier) - Constructor for class org.apache.kafka.streams.KafkaStreams
-
Create a KafkaStreams
instance.
- KafkaStreams(Topology, Properties, Time) - Constructor for class org.apache.kafka.streams.KafkaStreams
-
Create a KafkaStreams
instance.
- KafkaStreams(Topology, Properties, KafkaClientSupplier, Time) - Constructor for class org.apache.kafka.streams.KafkaStreams
-
Create a KafkaStreams
instance.
- KafkaStreams(Topology, StreamsConfig) - Constructor for class org.apache.kafka.streams.KafkaStreams
-
Create a KafkaStreams
instance.
- KafkaStreams(Topology, StreamsConfig, KafkaClientSupplier) - Constructor for class org.apache.kafka.streams.KafkaStreams
-
Create a KafkaStreams
instance.
- KafkaStreams(Topology, StreamsConfig, Time) - Constructor for class org.apache.kafka.streams.KafkaStreams
-
Create a KafkaStreams
instance.
- KafkaStreams(TopologyMetadata, StreamsConfig, KafkaClientSupplier) - Constructor for class org.apache.kafka.streams.KafkaStreams
-
- KafkaStreams.State - Enum in org.apache.kafka.streams
-
Kafka Streams states are the possible state that a Kafka Streams instance can be in.
- KafkaStreams.StateListener - Interface in org.apache.kafka.streams
-
- key - Variable in class org.apache.kafka.streams.KeyValue
-
The key of the key-value pair.
- key() - Method in class org.apache.kafka.streams.kstream.Windowed
-
Return the key of the window.
- key() - Method in class org.apache.kafka.streams.processor.api.Record
-
The key of the record.
- keyDeserializer() - Method in class org.apache.kafka.streams.state.StateSerdes
-
Return the key deserializer.
- keyFrom(byte[]) - Method in class org.apache.kafka.streams.state.StateSerdes
-
Deserialize the key from raw bytes.
- KeyQueryMetadata - Class in org.apache.kafka.streams
-
Represents all the metadata related to a key, where a particular key resides in a
KafkaStreams
application.
- KeyQueryMetadata(HostInfo, Set<HostInfo>, int) - Constructor for class org.apache.kafka.streams.KeyQueryMetadata
-
- keySerde - Variable in class org.apache.kafka.streams.kstream.Consumed
-
- keySerde - Variable in class org.apache.kafka.streams.kstream.Grouped
-
- keySerde(Serde<K>) - Static method in class org.apache.kafka.streams.kstream.Grouped
-
Create a
Grouped
instance with the provided keySerde.
- keySerde - Variable in class org.apache.kafka.streams.kstream.Joined
-
- keySerde(Serde<K>) - Static method in class org.apache.kafka.streams.kstream.Joined
-
Create an instance of Joined
with a key Serde
.
- keySerde() - Method in class org.apache.kafka.streams.kstream.Joined
-
- keySerde - Variable in class org.apache.kafka.streams.kstream.Materialized
-
- keySerde - Variable in class org.apache.kafka.streams.kstream.Produced
-
- keySerde(Serde<K>) - Static method in class org.apache.kafka.streams.kstream.Produced
-
Create a Produced instance with provided keySerde.
- keySerde - Variable in class org.apache.kafka.streams.kstream.Repartitioned
-
- keySerde - Variable in class org.apache.kafka.streams.kstream.StreamJoined
-
- keySerde() - Method in interface org.apache.kafka.streams.processor.api.ProcessorContext
-
Return the default key serde.
- keySerde() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
-
Return the default key serde.
- keySerde() - Method in interface org.apache.kafka.streams.processor.StateStoreContext
-
Returns the default key serde.
- keySerde() - Method in class org.apache.kafka.streams.state.StateSerdes
-
Return the key serde.
- keySerializer() - Method in class org.apache.kafka.streams.state.StateSerdes
-
Return the key serializer.
- KeyValue<K,V> - Class in org.apache.kafka.streams
-
A key-value pair defined for a single Kafka Streams record.
- KeyValue(K, V) - Constructor for class org.apache.kafka.streams.KeyValue
-
Create a new key-value pair.
- KeyValueBytesStoreSupplier - Interface in org.apache.kafka.streams.state
-
- KeyValueIterator<K,V> - Interface in org.apache.kafka.streams.state
-
- KeyValueMapper<K,V,VR> - Interface in org.apache.kafka.streams.kstream
-
The
KeyValueMapper
interface for mapping a
key-value pair
to a new value of arbitrary type.
- KeyValueStore<K,V> - Interface in org.apache.kafka.streams.state
-
A key-value store that supports put/get/delete and range queries.
- keyValueStore() - Static method in class org.apache.kafka.streams.state.QueryableStoreTypes
-
- keyValueStoreBuilder(KeyValueBytesStoreSupplier, Serde<K>, Serde<V>) - Static method in class org.apache.kafka.streams.state.Stores
-
- KGroupedStream<K,V> - Interface in org.apache.kafka.streams.kstream
-
KGroupedStream
is an abstraction of a
grouped record stream of
KeyValue
pairs.
- KGroupedTable<K,V> - Interface in org.apache.kafka.streams.kstream
-
KGroupedTable
is an abstraction of a re-grouped changelog stream from a primary-keyed table,
usually on a different grouping key than the original primary key.
- KStream<K,V> - Interface in org.apache.kafka.streams.kstream
-
KStream
is an abstraction of a
record stream of
KeyValue
pairs, i.e., each record is an
independent entity/event in the real world.
- KTable<K,V> - Interface in org.apache.kafka.streams.kstream
-
KTable
is an abstraction of a changelog stream from a primary-keyed table.
- main(String[]) - Static method in class org.apache.kafka.streams.StreamsConfig
-
- MAIN_CONSUMER_PREFIX - Static variable in class org.apache.kafka.streams.StreamsConfig
-
Prefix used to override consumer
configs for the main consumer client from
the general consumer client configs.
- mainConsumerPrefix(String) - Static method in class org.apache.kafka.streams.StreamsConfig
-
- make(V, long) - Static method in class org.apache.kafka.streams.state.ValueAndTimestamp
-
- map(KeyValueMapper<? super K, ? super V, ? extends KeyValue<? extends KR, ? extends VR>>) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Transform each record of the input stream into a new record in the output stream (both key and value type can be
altered arbitrarily).
- map(KeyValueMapper<? super K, ? super V, ? extends KeyValue<? extends KR, ? extends VR>>, Named) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Transform each record of the input stream into a new record in the output stream (both key and value type can be
altered arbitrarily).
- mapper - Variable in class org.apache.kafka.streams.kstream.Printed
-
- mapValues(ValueMapper<? super V, ? extends VR>) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Transform the value of each input record into a new value (with possible new type) of the output record.
- mapValues(ValueMapper<? super V, ? extends VR>, Named) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Transform the value of each input record into a new value (with possible new type) of the output record.
- mapValues(ValueMapperWithKey<? super K, ? super V, ? extends VR>) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Transform the value of each input record into a new value (with possible new type) of the output record.
- mapValues(ValueMapperWithKey<? super K, ? super V, ? extends VR>, Named) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Transform the value of each input record into a new value (with possible new type) of the output record.
- mapValues(ValueMapper<? super V, ? extends VR>) - Method in interface org.apache.kafka.streams.kstream.KTable
-
Create a new KTable
by transforming the value of each record in this KTable
into a new value
(with possibly a new type) in the new KTable
, with default serializers, deserializers, and state store.
- mapValues(ValueMapper<? super V, ? extends VR>, Named) - Method in interface org.apache.kafka.streams.kstream.KTable
-
Create a new KTable
by transforming the value of each record in this KTable
into a new value
(with possibly a new type) in the new KTable
, with default serializers, deserializers, and state store.
- mapValues(ValueMapperWithKey<? super K, ? super V, ? extends VR>) - Method in interface org.apache.kafka.streams.kstream.KTable
-
Create a new KTable
by transforming the value of each record in this KTable
into a new value
(with possibly a new type) in the new KTable
, with default serializers, deserializers, and state store.
- mapValues(ValueMapperWithKey<? super K, ? super V, ? extends VR>, Named) - Method in interface org.apache.kafka.streams.kstream.KTable
-
Create a new KTable
by transforming the value of each record in this KTable
into a new value
(with possibly a new type) in the new KTable
, with default serializers, deserializers, and state store.
- mapValues(ValueMapper<? super V, ? extends VR>, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KTable
-
Create a new
KTable
by transforming the value of each record in this
KTable
into a new value
(with possibly a new type) in the new
KTable
, with the
key serde
,
value serde
,
and the underlying
materialized state storage
configured in the
Materialized
instance.
- mapValues(ValueMapper<? super V, ? extends VR>, Named, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KTable
-
Create a new
KTable
by transforming the value of each record in this
KTable
into a new value
(with possibly a new type) in the new
KTable
, with the
key serde
,
value serde
,
and the underlying
materialized state storage
configured in the
Materialized
instance.
- mapValues(ValueMapperWithKey<? super K, ? super V, ? extends VR>, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KTable
-
Create a new
KTable
by transforming the value of each record in this
KTable
into a new value
(with possibly a new type) in the new
KTable
, with the
key serde
,
value serde
,
and the underlying
materialized state storage
configured in the
Materialized
instance.
- mapValues(ValueMapperWithKey<? super K, ? super V, ? extends VR>, Named, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KTable
-
Create a new
KTable
by transforming the value of each record in this
KTable
into a new value
(with possibly a new type) in the new
KTable
, with the
key serde
,
value serde
,
and the underlying
materialized state storage
configured in the
Materialized
instance.
- Materialized<K,V,S extends StateStore> - Class in org.apache.kafka.streams.kstream
-
Used to describe how a
StateStore
should be materialized.
- Materialized(Materialized<K, V, S>) - Constructor for class org.apache.kafka.streams.kstream.Materialized
-
Copy constructor.
- MAX_TASK_IDLE_MS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
max.task.idle.ms
- MAX_TASK_IDLE_MS_DISABLED - Static variable in class org.apache.kafka.streams.StreamsConfig
-
- MAX_WARMUP_REPLICAS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
max.warmup.replicas
- maxBytes(long) - Static method in interface org.apache.kafka.streams.kstream.Suppressed.BufferConfig
-
Create a size-constrained buffer in terms of the maximum number of bytes it will use.
- maxRecords(long) - Static method in interface org.apache.kafka.streams.kstream.Suppressed.BufferConfig
-
Create a size-constrained buffer in terms of the maximum number of keys it will store.
- merge(KStream<K, V>) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Merge this stream and the given stream into one larger stream.
- merge(KStream<K, V>, Named) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Merge this stream and the given stream into one larger stream.
- Merger<K,V> - Interface in org.apache.kafka.streams.kstream
-
The interface for merging aggregate values for
SessionWindows
with the given key.
- METADATA_MAX_AGE_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
metadata.max.age.ms
- metadataForAllStreamsClients() - Method in class org.apache.kafka.streams.KafkaStreams
-
Find all currently running
KafkaStreams
instances (potentially remotely) that use the same
application ID
as this instance (i.e., all instances that belong to
the same Kafka Streams application) and return
StreamsMetadata
for each discovered instance.
- metadataForLocalThreads() - Method in class org.apache.kafka.streams.KafkaStreams
-
Returns runtime information about the local threads of this
KafkaStreams
instance.
- METRIC_REPORTER_CLASSES_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
metric.reporters
- metrics() - Method in class org.apache.kafka.streams.KafkaStreams
-
Get read-only handle on global metrics registry, including streams client's own metrics plus
its embedded producer, consumer and admin clients' metrics.
- metrics() - Method in interface org.apache.kafka.streams.processor.api.ProcessorContext
-
Return Metrics instance.
- metrics() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
-
Return Metrics instance.
- metrics() - Method in interface org.apache.kafka.streams.processor.StateStoreContext
-
Returns Metrics instance.
- metrics() - Method in interface org.apache.kafka.streams.StreamsMetrics
-
Get read-only handle on global metrics registry.
- METRICS_LATEST - Static variable in class org.apache.kafka.streams.StreamsConfig
-
- METRICS_NUM_SAMPLES_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
metrics.num.samples
- METRICS_RECORDING_LEVEL_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
metrics.record.level
- METRICS_SAMPLE_WINDOW_MS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
metrics.sample.window.ms
- metricsScope() - Method in interface org.apache.kafka.streams.state.StoreSupplier
-
Return a String that is used as the scope for metrics recorded by Metered stores.
- MissingSourceTopicException - Exception in org.apache.kafka.streams.errors
-
- MissingSourceTopicException(String) - Constructor for exception org.apache.kafka.streams.errors.MissingSourceTopicException
-
- of(Duration) - Static method in class org.apache.kafka.streams.kstream.JoinWindows
-
- of(Duration) - Static method in class org.apache.kafka.streams.kstream.TimeWindows
-
- of() - Static method in class org.apache.kafka.streams.kstream.UnlimitedWindows
-
Return an unlimited window starting at timestamp zero.
- offset() - Method in interface org.apache.kafka.streams.processor.api.RecordMetadata
-
Return the offset of the current input record; could be -1
if it is not
available.
- offset() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
-
Return the offset of the current input record; could be -1
if it is not
available.
- offset() - Method in interface org.apache.kafka.streams.processor.RecordContext
-
Return the offset of the current input record; could be -1
if it is not
available.
- offsetLag() - Method in class org.apache.kafka.streams.LagInfo
-
Get the measured lag between current and end offset positions, for this store partition replica
- ofInactivityGapAndGrace(Duration, Duration) - Static method in class org.apache.kafka.streams.kstream.SessionWindows
-
Creates a new window specification with the specified inactivity gap.
- ofInactivityGapWithNoGrace(Duration) - Static method in class org.apache.kafka.streams.kstream.SessionWindows
-
Creates a new window specification with the specified inactivity gap.
- ofSizeAndGrace(Duration, Duration) - Static method in class org.apache.kafka.streams.kstream.TimeWindows
-
Return a window definition with the given window size, and with the advance interval being equal to the window
size.
- ofSizeWithNoGrace(Duration) - Static method in class org.apache.kafka.streams.kstream.TimeWindows
-
Return a window definition with the given window size, and with the advance interval being equal to the window
size.
- ofTimeDifferenceAndGrace(Duration, Duration) - Static method in class org.apache.kafka.streams.kstream.JoinWindows
-
Specifies that records of the same key are joinable if their timestamps are within timeDifference
,
i.e., the timestamp of a record from the secondary stream is max timeDifference
before or after
the timestamp of the record from the primary stream.
- ofTimeDifferenceAndGrace(Duration, Duration) - Static method in class org.apache.kafka.streams.kstream.SlidingWindows
-
Return a window definition with the window size based on the given maximum time difference (inclusive) between
records in the same window and given window grace period.
- ofTimeDifferenceWithNoGrace(Duration) - Static method in class org.apache.kafka.streams.kstream.JoinWindows
-
Specifies that records of the same key are joinable if their timestamps are within timeDifference
,
i.e., the timestamp of a record from the secondary stream is max timeDifference
before or after
the timestamp of the record from the primary stream.
- ofTimeDifferenceWithNoGrace(Duration) - Static method in class org.apache.kafka.streams.kstream.SlidingWindows
-
Return a window definition with the window size based on the given maximum time difference (inclusive) between
records in the same window and given window grace period.
- onBatchRestored(TopicPartition, String, long, long) - Method in interface org.apache.kafka.streams.processor.StateRestoreListener
-
Method called after restoring a batch of records.
- onChange(KafkaStreams.State, KafkaStreams.State) - Method in interface org.apache.kafka.streams.KafkaStreams.StateListener
-
Called when state changes.
- onInvalidTimestamp(ConsumerRecord<Object, Object>, long, long) - Method in class org.apache.kafka.streams.processor.FailOnInvalidTimestamp
-
Raises an exception on every call.
- onInvalidTimestamp(ConsumerRecord<Object, Object>, long, long) - Method in class org.apache.kafka.streams.processor.LogAndSkipOnInvalidTimestamp
-
Writes a log WARN message when the extracted timestamp is invalid (negative) but returns the invalid timestamp as-is,
which ultimately causes the record to be skipped and not to be processed.
- onInvalidTimestamp(ConsumerRecord<Object, Object>, long, long) - Method in class org.apache.kafka.streams.processor.UsePartitionTimeOnInvalidTimestamp
-
Returns the current stream-time as new timestamp for the record.
- onRestoreEnd(TopicPartition, String, long) - Method in interface org.apache.kafka.streams.processor.StateRestoreListener
-
Method called when restoring the
StateStore
is complete.
- onRestoreStart(TopicPartition, String, long, long) - Method in interface org.apache.kafka.streams.processor.StateRestoreListener
-
Method called at the very beginning of
StateStore
restoration.
- OPTIMIZE - Static variable in class org.apache.kafka.streams.StreamsConfig
-
- org.apache.kafka.streams - package org.apache.kafka.streams
-
- org.apache.kafka.streams.errors - package org.apache.kafka.streams.errors
-
- org.apache.kafka.streams.kstream - package org.apache.kafka.streams.kstream
-
- org.apache.kafka.streams.processor - package org.apache.kafka.streams.processor
-
- org.apache.kafka.streams.processor.api - package org.apache.kafka.streams.processor.api
-
- org.apache.kafka.streams.state - package org.apache.kafka.streams.state
-
- otherPartitioner - Variable in class org.apache.kafka.streams.kstream.TableJoined
-
- otherStoreSupplier - Variable in class org.apache.kafka.streams.kstream.StreamJoined
-
- otherValueSerde - Variable in class org.apache.kafka.streams.kstream.Joined
-
- otherValueSerde(Serde<VO>) - Static method in class org.apache.kafka.streams.kstream.Joined
-
Create an instance of Joined
with an other value Serde
.
- otherValueSerde() - Method in class org.apache.kafka.streams.kstream.Joined
-
- otherValueSerde - Variable in class org.apache.kafka.streams.kstream.StreamJoined
-
- outerJoin(KStream<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, JoinWindows) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Join records of this stream with another KStream
's records using windowed outer equi join with default
serializers and deserializers.
- outerJoin(KStream<K, VO>, ValueJoinerWithKey<? super K, ? super V, ? super VO, ? extends VR>, JoinWindows) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Join records of this stream with another KStream
's records using windowed outer equi join with default
serializers and deserializers.
- outerJoin(KStream<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, JoinWindows, StreamJoined<K, V, VO>) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Join records of this stream with another
KStream
's records using windowed outer equi join using the
StreamJoined
instance for configuration of the
key serde
,
this stream's value
serde
,
the other stream's value serde
, and used state stores.
- outerJoin(KStream<K, VO>, ValueJoinerWithKey<? super K, ? super V, ? super VO, ? extends VR>, JoinWindows, StreamJoined<K, V, VO>) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Join records of this stream with another
KStream
's records using windowed outer equi join using the
StreamJoined
instance for configuration of the
key serde
,
this stream's value
serde
,
the other stream's value serde
, and used state stores.
- outerJoin(KTable<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>) - Method in interface org.apache.kafka.streams.kstream.KTable
-
Join records of this KTable
(left input) with another KTable
's (right input) records using
non-windowed outer equi join, with default serializers, deserializers, and state store.
- outerJoin(KTable<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, Named) - Method in interface org.apache.kafka.streams.kstream.KTable
-
Join records of this KTable
(left input) with another KTable
's (right input) records using
non-windowed outer equi join, with default serializers, deserializers, and state store.
- outerJoin(KTable<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KTable
-
Join records of this
KTable
(left input) with another
KTable
's (right input) records using
non-windowed outer equi join, with the
Materialized
instance for configuration of the
key serde
,
the result table's value serde
, and
state store
.
- outerJoin(KTable<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, Named, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KTable
-
Join records of this
KTable
(left input) with another
KTable
's (right input) records using
non-windowed outer equi join, with the
Materialized
instance for configuration of the
key serde
,
the result table's value serde
, and
state store
.
- outputStream - Variable in class org.apache.kafka.streams.kstream.Printed
-
- overlap(Window) - Method in class org.apache.kafka.streams.kstream.Window
-
Check if the given window overlaps with this window.
- pair(K, V) - Static method in class org.apache.kafka.streams.KeyValue
-
Create a new key-value pair.
- parse(String) - Static method in class org.apache.kafka.streams.processor.TaskId
-
- partition() - Method in class org.apache.kafka.streams.KeyQueryMetadata
-
Get the store partition corresponding to the key.
- partition() - Method in interface org.apache.kafka.streams.processor.api.RecordMetadata
-
Return the partition id of the current input record; could be -1
if it is not
available.
- partition() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
-
Return the partition id of the current input record; could be -1
if it is not
available.
- partition() - Method in interface org.apache.kafka.streams.processor.RecordContext
-
Return the partition id of the current input record; could be -1
if it is not
available.
- partition(String, K, V, int) - Method in interface org.apache.kafka.streams.processor.StreamPartitioner
-
Determine the partition number for a record with the given key and value and the current number of partitions.
- partition - Variable in class org.apache.kafka.streams.processor.TaskId
-
Deprecated.
- partition() - Method in class org.apache.kafka.streams.processor.TaskId
-
- partition() - Method in class org.apache.kafka.streams.StoreQueryParameters
-
Get the store partition that will be queried.
- partitioner - Variable in class org.apache.kafka.streams.kstream.Produced
-
- partitioner - Variable in class org.apache.kafka.streams.kstream.Repartitioned
-
- partitioner - Variable in class org.apache.kafka.streams.kstream.TableJoined
-
- peek(ForeachAction<? super K, ? super V>) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Perform an action on each record of KStream
.
- peek(ForeachAction<? super K, ? super V>, Named) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Perform an action on each record of KStream
.
- peekNextKey() - Method in interface org.apache.kafka.streams.state.KeyValueIterator
-
Peek at the next key without advancing the iterator
- persistent() - Method in interface org.apache.kafka.streams.processor.StateStore
-
Return if the storage is persistent or not.
- persistentKeyValueStore(String) - Static method in class org.apache.kafka.streams.state.Stores
-
- persistentSessionStore(String, Duration) - Static method in class org.apache.kafka.streams.state.Stores
-
- persistentTimestampedKeyValueStore(String) - Static method in class org.apache.kafka.streams.state.Stores
-
- persistentTimestampedWindowStore(String, Duration, Duration, boolean) - Static method in class org.apache.kafka.streams.state.Stores
-
- persistentWindowStore(String, Duration, Duration, boolean) - Static method in class org.apache.kafka.streams.state.Stores
-
- POLL_MS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
poll.ms
- port() - Method in class org.apache.kafka.streams.state.HostInfo
-
- port() - Method in class org.apache.kafka.streams.state.StreamsMetadata
-
Deprecated.
- port() - Method in interface org.apache.kafka.streams.StreamsMetadata
-
Port on which the Streams client listens.
- postProcessParsedConfig(Map<String, Object>) - Method in class org.apache.kafka.streams.StreamsConfig
-
- predecessors() - Method in interface org.apache.kafka.streams.TopologyDescription.Node
-
The predecessors of this node within a sub-topology.
- Predicate<K,V> - Interface in org.apache.kafka.streams.kstream
-
The
Predicate
interface represents a predicate (boolean-valued function) of a
KeyValue
pair.
- prefixScan(P, PS) - Method in interface org.apache.kafka.streams.state.ReadOnlyKeyValueStore
-
Return an iterator over all keys with the specified prefix.
- print(Printed<K, V>) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Print the records of this KStream using the options provided by
Printed
Note that this is mainly for debugging/testing purposes, and it will try to flush on each record print.
- Printed<K,V> - Class in org.apache.kafka.streams.kstream
-
An object to define the options used when printing a
KStream
.
- Printed(Printed<K, V>) - Constructor for class org.apache.kafka.streams.kstream.Printed
-
Copy constructor.
- PROBING_REBALANCE_INTERVAL_MS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
probing.rebalance.interval.ms
- process(Record<K, V>) - Method in class org.apache.kafka.streams.kstream.ForeachProcessor
-
- process(ProcessorSupplier<? super K, ? super V>, String...) - Method in interface org.apache.kafka.streams.kstream.KStream
-
- process(ProcessorSupplier<? super K, ? super V, Void, Void>, String...) - Method in interface org.apache.kafka.streams.kstream.KStream
-
- process(ProcessorSupplier<? super K, ? super V>, Named, String...) - Method in interface org.apache.kafka.streams.kstream.KStream
-
- process(ProcessorSupplier<? super K, ? super V, Void, Void>, Named, String...) - Method in interface org.apache.kafka.streams.kstream.KStream
-
- process(Record<KIn, VIn>) - Method in interface org.apache.kafka.streams.processor.api.Processor
-
Process the record.
- process(K, V) - Method in interface org.apache.kafka.streams.processor.Processor
-
Deprecated.
Process the record with the given key and value.
- PROCESSING_GUARANTEE_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
processing.guarantee
- Processor<KIn,VIn,KOut,VOut> - Interface in org.apache.kafka.streams.processor.api
-
A processor of key-value pair records.
- Processor<K,V> - Interface in org.apache.kafka.streams.processor
-
- processor() - Method in interface org.apache.kafka.streams.TopologyDescription.GlobalStore
-
The processor node maintaining the global store.
- ProcessorContext<KForward,VForward> - Interface in org.apache.kafka.streams.processor.api
-
Processor context interface.
- ProcessorContext - Interface in org.apache.kafka.streams.processor
-
Processor context interface.
- processorName - Variable in class org.apache.kafka.streams.kstream.Consumed
-
- processorName - Variable in class org.apache.kafka.streams.kstream.Printed
-
- processorName - Variable in class org.apache.kafka.streams.kstream.Produced
-
- ProcessorStateException - Exception in org.apache.kafka.streams.errors
-
Indicates a processor state operation (e.g.
- ProcessorStateException(String) - Constructor for exception org.apache.kafka.streams.errors.ProcessorStateException
-
- ProcessorStateException(String, Throwable) - Constructor for exception org.apache.kafka.streams.errors.ProcessorStateException
-
- ProcessorStateException(Throwable) - Constructor for exception org.apache.kafka.streams.errors.ProcessorStateException
-
- ProcessorSupplier<KIn,VIn,KOut,VOut> - Interface in org.apache.kafka.streams.processor.api
-
A processor supplier that can create one or more
Processor
instances.
- ProcessorSupplier<K,V> - Interface in org.apache.kafka.streams.processor
-
- processStreamThread(Consumer<StreamThread>) - Method in class org.apache.kafka.streams.KafkaStreams
-
handle each stream thread in a snapshot of threads.
- Produced<K,V> - Class in org.apache.kafka.streams.kstream
-
- Produced(Produced<K, V>) - Constructor for class org.apache.kafka.streams.kstream.Produced
-
- PRODUCER_PREFIX - Static variable in class org.apache.kafka.streams.StreamsConfig
-
Prefix used to isolate producer
configs from other client configs.
- producerClientIds() - Method in class org.apache.kafka.streams.processor.ThreadMetadata
-
Deprecated.
- producerClientIds() - Method in interface org.apache.kafka.streams.ThreadMetadata
-
Client IDs of the Kafka producers used by the stream thread.
- producerPrefix(String) - Static method in class org.apache.kafka.streams.StreamsConfig
-
- ProductionExceptionHandler - Interface in org.apache.kafka.streams.errors
-
Interface that specifies how an exception when attempting to produce a result to
Kafka should be handled.
- ProductionExceptionHandler.ProductionExceptionHandlerResponse - Enum in org.apache.kafka.streams.errors
-
- punctuate(long) - Method in interface org.apache.kafka.streams.processor.Punctuator
-
Perform the scheduled periodic operation.
- PunctuationType - Enum in org.apache.kafka.streams.processor
-
- Punctuator - Interface in org.apache.kafka.streams.processor
-
- put(K, V) - Method in interface org.apache.kafka.streams.state.KeyValueStore
-
Update the value associated with this key.
- put(Windowed<K>, AGG) - Method in interface org.apache.kafka.streams.state.SessionStore
-
Write the aggregated value for the provided key to the store
- put(K, V, long) - Method in interface org.apache.kafka.streams.state.WindowStore
-
Put a key-value pair into the window with given window start timestamp
- putAll(List<KeyValue<K, V>>) - Method in interface org.apache.kafka.streams.state.KeyValueStore
-
Update all the given key/value pairs.
- putIfAbsent(K, V) - Method in interface org.apache.kafka.streams.state.KeyValueStore
-
Update the value associated with this key, unless a value is already associated with the key.
- range(K, K) - Method in interface org.apache.kafka.streams.state.ReadOnlyKeyValueStore
-
Get an iterator over a given range of keys.
- rawKey(K) - Method in class org.apache.kafka.streams.state.StateSerdes
-
Serialize the given key.
- rawValue(V) - Method in class org.apache.kafka.streams.state.StateSerdes
-
Serialize the given value.
- readFrom(DataInputStream, int) - Static method in class org.apache.kafka.streams.processor.TaskId
-
- readFrom(ByteBuffer, int) - Static method in class org.apache.kafka.streams.processor.TaskId
-
- ReadOnlyKeyValueStore<K,V> - Interface in org.apache.kafka.streams.state
-
A key-value store that only supports read operations.
- ReadOnlySessionStore<K,AGG> - Interface in org.apache.kafka.streams.state
-
A session store that only supports read operations.
- ReadOnlyWindowStore<K,V> - Interface in org.apache.kafka.streams.state
-
A window store that only supports read operations.
- RECEIVE_BUFFER_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
receive.buffer.bytes
- RECONNECT_BACKOFF_MAX_MS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
reconnect.backoff.max
- RECONNECT_BACKOFF_MS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
reconnect.backoff.ms
- Record<K,V> - Class in org.apache.kafka.streams.processor.api
-
A data class representing an incoming record for processing in a
Processor
or a record to forward to downstream processors via
ProcessorContext
.
- Record(K, V, long, Headers) - Constructor for class org.apache.kafka.streams.processor.api.Record
-
The full constructor, specifying all the attributes of the record.
- Record(K, V, long) - Constructor for class org.apache.kafka.streams.processor.api.Record
-
Convenience constructor in case you do not wish to specify any headers.
- RecordContext - Interface in org.apache.kafka.streams.processor
-
The context associated with the current record being processed by
an
Processor
- recordMetadata() - Method in interface org.apache.kafka.streams.processor.api.ProcessorContext
-
Return the metadata of the current record if available.
- RecordMetadata - Interface in org.apache.kafka.streams.processor.api
-
- reduce(Reducer<V>) - Method in interface org.apache.kafka.streams.kstream.KGroupedStream
-
Combine the values of records in this stream by the grouped key.
- reduce(Reducer<V>, Materialized<K, V, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KGroupedStream
-
Combine the value of records in this stream by the grouped key.
- reduce(Reducer<V>, Named, Materialized<K, V, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KGroupedStream
-
Combine the value of records in this stream by the grouped key.
- reduce(Reducer<V>, Reducer<V>, Materialized<K, V, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KGroupedTable
-
Combine the value of records of the original
KTable
that got
mapped
to the same key into a new instance of
KTable
.
- reduce(Reducer<V>, Reducer<V>, Named, Materialized<K, V, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KGroupedTable
-
Combine the value of records of the original
KTable
that got
mapped
to the same key into a new instance of
KTable
.
- reduce(Reducer<V>, Reducer<V>) - Method in interface org.apache.kafka.streams.kstream.KGroupedTable
-
Combine the value of records of the original
KTable
that got
mapped
to the same key into a new instance of
KTable
.
- reduce(Reducer<V>) - Method in interface org.apache.kafka.streams.kstream.SessionWindowedKStream
-
Combine the values of records in this stream by the grouped key and defined sessions.
- reduce(Reducer<V>, Named) - Method in interface org.apache.kafka.streams.kstream.SessionWindowedKStream
-
Combine the values of records in this stream by the grouped key and defined sessions.
- reduce(Reducer<V>, Materialized<K, V, SessionStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.SessionWindowedKStream
-
Combine the values of records in this stream by the grouped key and defined sessions.
- reduce(Reducer<V>, Named, Materialized<K, V, SessionStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.SessionWindowedKStream
-
Combine the values of records in this stream by the grouped key and defined sessions.
- reduce(Reducer<V>) - Method in interface org.apache.kafka.streams.kstream.TimeWindowedKStream
-
Combine the values of records in this stream by the grouped key and defined windows.
- reduce(Reducer<V>, Named) - Method in interface org.apache.kafka.streams.kstream.TimeWindowedKStream
-
Combine the values of records in this stream by the grouped key and defined windows.
- reduce(Reducer<V>, Materialized<K, V, WindowStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.TimeWindowedKStream
-
Combine the values of records in this stream by the grouped key and defined windows.
- reduce(Reducer<V>, Named, Materialized<K, V, WindowStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.TimeWindowedKStream
-
Combine the values of records in this stream by the grouped key and defined windows.
- Reducer<V> - Interface in org.apache.kafka.streams.kstream
-
The Reducer
interface for combining two values of the same type into a new value.
- REFERENCE_CONTAINER_PARTITION_ASSIGNOR - Static variable in class org.apache.kafka.streams.StreamsConfig.InternalConfig
-
- register(StateStore, StateRestoreCallback) - Method in interface org.apache.kafka.streams.processor.ProcessorContext
-
Register and possibly restores the specified storage engine.
- register(StateStore, StateRestoreCallback) - Method in interface org.apache.kafka.streams.processor.StateStoreContext
-
Registers and possibly restores the specified storage engine.
- remove(Windowed<K>) - Method in interface org.apache.kafka.streams.state.SessionStore
-
Remove the session aggregated with provided
Windowed
key from the store
- removeSensor(Sensor) - Method in interface org.apache.kafka.streams.StreamsMetrics
-
Remove a sensor.
- removeStreamThread() - Method in class org.apache.kafka.streams.KafkaStreams
-
Removes one stream thread out of the running stream threads from this Kafka Streams client.
- removeStreamThread(Duration) - Method in class org.apache.kafka.streams.KafkaStreams
-
Removes one stream thread out of the running stream threads from this Kafka Streams client.
- repartition() - Method in interface org.apache.kafka.streams.kstream.KStream
-
Materialize this stream to an auto-generated repartition topic and create a new KStream
from the auto-generated topic using default serializers, deserializers, and producer's DefaultPartitioner
.
- repartition(Repartitioned<K, V>) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Materialize this stream to an auto-generated repartition topic and create a new
KStream
from the auto-generated topic using
key serde
,
value serde
,
StreamPartitioner
,
number of partitions, and topic name part as defined by
Repartitioned
.
- Repartitioned<K,V> - Class in org.apache.kafka.streams.kstream
-
This class is used to provide the optional parameters for internal repartition topics.
- Repartitioned(Repartitioned<K, V>) - Constructor for class org.apache.kafka.streams.kstream.Repartitioned
-
- REPLICATION_FACTOR_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
replication.factor
- REQUEST_TIMEOUT_MS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
request.timeout.ms
- resetPolicy - Variable in class org.apache.kafka.streams.kstream.Consumed
-
- restore(byte[], byte[]) - Method in interface org.apache.kafka.streams.processor.BatchingStateRestoreCallback
-
- restore(byte[], byte[]) - Method in interface org.apache.kafka.streams.processor.StateRestoreCallback
-
- RESTORE_CONSUMER_PREFIX - Static variable in class org.apache.kafka.streams.StreamsConfig
-
Prefix used to override consumer
configs for the restore consumer client from
the general consumer client configs.
- restoreAll(Collection<KeyValue<byte[], byte[]>>) - Method in interface org.apache.kafka.streams.processor.BatchingStateRestoreCallback
-
Called to restore a number of records.
- restoreConsumerClientId() - Method in class org.apache.kafka.streams.processor.ThreadMetadata
-
Deprecated.
- restoreConsumerClientId() - Method in interface org.apache.kafka.streams.ThreadMetadata
-
Client ID of the restore Kafka consumer used by the stream thread
- restoreConsumerPrefix(String) - Static method in class org.apache.kafka.streams.StreamsConfig
-
- retainDuplicates() - Method in interface org.apache.kafka.streams.state.WindowBytesStoreSupplier
-
Whether or not this store is retaining duplicate keys.
- retention - Variable in class org.apache.kafka.streams.kstream.Materialized
-
- retentionPeriod() - Method in interface org.apache.kafka.streams.state.SessionBytesStoreSupplier
-
The time period for which the
SessionStore
will retain historic data.
- retentionPeriod() - Method in interface org.apache.kafka.streams.state.WindowBytesStoreSupplier
-
The time period for which the
WindowStore
will retain historic data.
- RETRIES_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
- RETRY_BACKOFF_MS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
retry.backoff.ms
- reverseAll() - Method in interface org.apache.kafka.streams.state.ReadOnlyKeyValueStore
-
Return a reverse iterator over all keys in this store.
- reverseRange(K, K) - Method in interface org.apache.kafka.streams.state.ReadOnlyKeyValueStore
-
Get a reverse iterator over a given range of keys.
- ROCKSDB_CONFIG_SETTER_CLASS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
rocksdb.config.setter
- RocksDBConfigSetter - Interface in org.apache.kafka.streams.state
-
An interface to that allows developers to customize the RocksDB settings for a given Store.
- schedule(Duration, PunctuationType, Punctuator) - Method in interface org.apache.kafka.streams.processor.api.ProcessorContext
-
Schedule a periodic operation for processors.
- schedule(Duration, PunctuationType, Punctuator) - Method in interface org.apache.kafka.streams.processor.ProcessorContext
-
Schedule a periodic operation for processors.
- SECURITY_PROTOCOL_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
security.protocol
- segmentIntervalMs() - Method in interface org.apache.kafka.streams.state.SessionBytesStoreSupplier
-
The size of a segment, in milliseconds.
- segmentIntervalMs() - Method in interface org.apache.kafka.streams.state.WindowBytesStoreSupplier
-
The size of the segments (in milliseconds) the store has.
- selectKey(KeyValueMapper<? super K, ? super V, ? extends KR>) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Set a new key (with possibly new type) for each input record.
- selectKey(KeyValueMapper<? super K, ? super V, ? extends KR>, Named) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Set a new key (with possibly new type) for each input record.
- SEND_BUFFER_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
send.buffer.bytes
- serialize(String, Windowed<T>) - Method in class org.apache.kafka.streams.kstream.SessionWindowedSerializer
-
- serialize(String, Windowed<T>) - Method in class org.apache.kafka.streams.kstream.TimeWindowedSerializer
-
- serializeBaseKey(String, Windowed<T>) - Method in class org.apache.kafka.streams.kstream.SessionWindowedSerializer
-
- serializeBaseKey(String, Windowed<T>) - Method in class org.apache.kafka.streams.kstream.TimeWindowedSerializer
-
- SessionBytesStoreSupplier - Interface in org.apache.kafka.streams.state
-
- sessionStore() - Static method in class org.apache.kafka.streams.state.QueryableStoreTypes
-
- SessionStore<K,AGG> - Interface in org.apache.kafka.streams.state
-
Interface for storing the aggregated values of sessions.
- sessionStoreBuilder(SessionBytesStoreSupplier, Serde<K>, Serde<V>) - Static method in class org.apache.kafka.streams.state.Stores
-
- SessionWindowedCogroupedKStream<K,V> - Interface in org.apache.kafka.streams.kstream
-
SessionWindowedCogroupKStream
is an abstraction of a
windowed record stream of
KeyValue
pairs.
- SessionWindowedDeserializer<T> - Class in org.apache.kafka.streams.kstream
-
- SessionWindowedDeserializer() - Constructor for class org.apache.kafka.streams.kstream.SessionWindowedDeserializer
-
- SessionWindowedDeserializer(Deserializer<T>) - Constructor for class org.apache.kafka.streams.kstream.SessionWindowedDeserializer
-
- SessionWindowedKStream<K,V> - Interface in org.apache.kafka.streams.kstream
-
SessionWindowedKStream
is an abstraction of a
windowed record stream of
KeyValue
pairs.
- SessionWindowedSerde() - Constructor for class org.apache.kafka.streams.kstream.WindowedSerdes.SessionWindowedSerde
-
- SessionWindowedSerde(Serde<T>) - Constructor for class org.apache.kafka.streams.kstream.WindowedSerdes.SessionWindowedSerde
-
- sessionWindowedSerdeFrom(Class<T>) - Static method in class org.apache.kafka.streams.kstream.WindowedSerdes
-
Construct a SessionWindowedSerde
object for the specified inner class type.
- SessionWindowedSerializer<T> - Class in org.apache.kafka.streams.kstream
-
- SessionWindowedSerializer() - Constructor for class org.apache.kafka.streams.kstream.SessionWindowedSerializer
-
- SessionWindowedSerializer(Serializer<T>) - Constructor for class org.apache.kafka.streams.kstream.SessionWindowedSerializer
-
- SessionWindows - Class in org.apache.kafka.streams.kstream
-
A session based window specification used for aggregating events into sessions.
- setConfig(String, Options, Map<String, Object>) - Method in interface org.apache.kafka.streams.state.RocksDBConfigSetter
-
Set the rocks db options for the provided storeName.
- setGlobalStateRestoreListener(StateRestoreListener) - Method in class org.apache.kafka.streams.KafkaStreams
-
Set the listener which is triggered whenever a
StateStore
is being restored in order to resume
processing.
- setIsChangelogTopic(boolean) - Method in class org.apache.kafka.streams.kstream.TimeWindowedDeserializer
-
- setStateListener(KafkaStreams.StateListener) - Method in class org.apache.kafka.streams.KafkaStreams
-
- setTaskId(TaskId) - Method in exception org.apache.kafka.streams.errors.StreamsException
-
- setUncaughtExceptionHandler(Thread.UncaughtExceptionHandler) - Method in class org.apache.kafka.streams.KafkaStreams
-
- setUncaughtExceptionHandler(StreamsUncaughtExceptionHandler) - Method in class org.apache.kafka.streams.KafkaStreams
-
Set the handler invoked when an internal
stream thread
throws an unexpected exception.
- shutDownWhenFull() - Method in interface org.apache.kafka.streams.kstream.Suppressed.BufferConfig
-
Set the buffer to gracefully shut down the application when any of its constraints are violated
This buffer is "strict" in the sense that it will enforce the time bound or shut down.
- size() - Method in class org.apache.kafka.streams.kstream.JoinWindows
-
- size() - Method in class org.apache.kafka.streams.kstream.TimeWindows
-
- size() - Method in class org.apache.kafka.streams.kstream.UnlimitedWindows
-
Return the size of the specified windows in milliseconds.
- size() - Method in class org.apache.kafka.streams.kstream.Windows
-
Return the size of the specified windows in milliseconds.
- sizeMs - Variable in class org.apache.kafka.streams.kstream.TimeWindows
-
The size of the windows in milliseconds.
- SlidingWindows - Class in org.apache.kafka.streams.kstream
-
A sliding window used for aggregating events.
- source() - Method in interface org.apache.kafka.streams.TopologyDescription.GlobalStore
-
The source node reading from a "global" topic.
- split() - Method in interface org.apache.kafka.streams.kstream.KStream
-
Split this stream into different branches.
- split(Named) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Split this stream into different branches.
- staleStoresEnabled() - Method in class org.apache.kafka.streams.StoreQueryParameters
-
Get the flag staleStores.
- standbyHosts() - Method in class org.apache.kafka.streams.KeyQueryMetadata
-
Get the Kafka Streams instances that host the key as standbys.
- standbyStateStoreNames() - Method in class org.apache.kafka.streams.state.StreamsMetadata
-
Deprecated.
State stores owned by the instance as a standby replica
- standbyStateStoreNames() - Method in interface org.apache.kafka.streams.StreamsMetadata
-
Names of the state stores assigned to standby tasks of the Streams client.
- standbyTasks() - Method in class org.apache.kafka.streams.processor.ThreadMetadata
-
Deprecated.
- standbyTasks() - Method in interface org.apache.kafka.streams.ThreadMetadata
-
Metadata of the standby tasks assigned to the stream thread.
- standbyTopicPartitions() - Method in class org.apache.kafka.streams.state.StreamsMetadata
-
Deprecated.
(Source) Topic partitions for which the instance acts as standby.
- standbyTopicPartitions() - Method in interface org.apache.kafka.streams.StreamsMetadata
-
Changelog topic partitions for the state stores the standby tasks of the Streams client replicates.
- start() - Method in class org.apache.kafka.streams.KafkaStreams
-
Start the KafkaStreams
instance by starting all its threads.
- start() - Method in class org.apache.kafka.streams.kstream.Window
-
Return the start timestamp of this window.
- startMs - Variable in class org.apache.kafka.streams.kstream.UnlimitedWindows
-
The start timestamp of the window.
- startMs - Variable in class org.apache.kafka.streams.kstream.Window
-
- startOn(Instant) - Method in class org.apache.kafka.streams.kstream.UnlimitedWindows
-
Return a new unlimited window for the specified start timestamp.
- startTime() - Method in class org.apache.kafka.streams.kstream.Window
-
Return the start time of this window.
- state - Variable in class org.apache.kafka.streams.KafkaStreams
-
- state() - Method in class org.apache.kafka.streams.KafkaStreams
-
- STATE_CLEANUP_DELAY_MS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
state.cleanup.delay
- STATE_DIR_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
state.dir
- stateDir() - Method in interface org.apache.kafka.streams.processor.api.ProcessorContext
-
Return the state directory for the partition.
- stateDir() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
-
Return the state directory for the partition.
- stateDir() - Method in interface org.apache.kafka.streams.processor.StateStoreContext
-
Returns the state directory for the partition.
- stateDirectory - Variable in class org.apache.kafka.streams.KafkaStreams
-
- StateRestoreCallback - Interface in org.apache.kafka.streams.processor
-
Restoration logic for log-backed state stores upon restart,
it takes one record at a time from the logs to apply to the restoring state.
- StateRestoreListener - Interface in org.apache.kafka.streams.processor
-
Class for listening to various states of the restoration process of a StateStore.
- StateSerdes<K,V> - Class in org.apache.kafka.streams.state
-
Factory for creating serializers / deserializers for state stores in Kafka Streams.
- StateSerdes(String, Serde<K>, Serde<V>) - Constructor for class org.apache.kafka.streams.state.StateSerdes
-
Create a context for serialization using the specified serializers and deserializers which
must match the key and value types used as parameters for this object; the state changelog topic
is provided to bind this serde factory to, so that future calls for serialize / deserialize do not
need to provide the topic name any more.
- StateStore - Interface in org.apache.kafka.streams.processor
-
A storage engine for managing state maintained by a stream processor.
- StateStoreContext - Interface in org.apache.kafka.streams.processor
-
State store context interface.
- StateStoreMigratedException - Exception in org.apache.kafka.streams.errors
-
Indicates that the state store being queried is closed although the Kafka Streams state is
RUNNING
or
REBALANCING
.
- StateStoreMigratedException(String) - Constructor for exception org.apache.kafka.streams.errors.StateStoreMigratedException
-
- StateStoreMigratedException(String, Throwable) - Constructor for exception org.apache.kafka.streams.errors.StateStoreMigratedException
-
- stateStoreNames() - Method in class org.apache.kafka.streams.state.StreamsMetadata
-
Deprecated.
State stores owned by the instance as an active replica
- stateStoreNames() - Method in interface org.apache.kafka.streams.StreamsMetadata
-
Names of the state stores assigned to active tasks of the Streams client.
- StateStoreNotAvailableException - Exception in org.apache.kafka.streams.errors
-
Indicates that the state store being queried is already closed.
- StateStoreNotAvailableException(String) - Constructor for exception org.apache.kafka.streams.errors.StateStoreNotAvailableException
-
- StateStoreNotAvailableException(String, Throwable) - Constructor for exception org.apache.kafka.streams.errors.StateStoreNotAvailableException
-
- store(StoreQueryParameters<T>) - Method in class org.apache.kafka.streams.KafkaStreams
-
- StoreBuilder<T extends StateStore> - Interface in org.apache.kafka.streams.state
-
Build a
StateStore
wrapped with optional caching and logging.
- storeName - Variable in class org.apache.kafka.streams.kstream.Materialized
-
- storeName - Variable in class org.apache.kafka.streams.kstream.StreamJoined
-
- storeName() - Method in class org.apache.kafka.streams.StoreQueryParameters
-
Get the name of the state store that should be queried.
- StoreQueryParameters<T> - Class in org.apache.kafka.streams
-
StoreQueryParameters
allows you to pass a variety of parameters when fetching a store for interactive query.
- stores() - Method in interface org.apache.kafka.streams.processor.ConnectedStoreProvider
-
- Stores - Class in org.apache.kafka.streams.state
-
Factory for creating state stores in Kafka Streams.
- Stores() - Constructor for class org.apache.kafka.streams.state.Stores
-
- stores() - Method in interface org.apache.kafka.streams.TopologyDescription.Processor
-
The names of all connected stores.
- storeSupplier - Variable in class org.apache.kafka.streams.kstream.Materialized
-
- StoreSupplier<T extends StateStore> - Interface in org.apache.kafka.streams.state
-
A state store supplier which can create one or more
StateStore
instances.
- stream(String) - Method in class org.apache.kafka.streams.StreamsBuilder
-
Create a
KStream
from the specified topic.
- stream(String, Consumed<K, V>) - Method in class org.apache.kafka.streams.StreamsBuilder
-
Create a
KStream
from the specified topic.
- stream(Collection<String>) - Method in class org.apache.kafka.streams.StreamsBuilder
-
Create a
KStream
from the specified topics.
- stream(Collection<String>, Consumed<K, V>) - Method in class org.apache.kafka.streams.StreamsBuilder
-
Create a
KStream
from the specified topics.
- stream(Pattern) - Method in class org.apache.kafka.streams.StreamsBuilder
-
Create a
KStream
from the specified topic pattern.
- stream(Pattern, Consumed<K, V>) - Method in class org.apache.kafka.streams.StreamsBuilder
-
Create a
KStream
from the specified topic pattern.
- StreamJoined<K,V1,V2> - Class in org.apache.kafka.streams.kstream
-
Class used to configure the name of the join processor, the repartition topic name,
state stores or state store names in Stream-Stream join.
- StreamJoined(StreamJoined<K, V1, V2>) - Constructor for class org.apache.kafka.streams.kstream.StreamJoined
-
- streamPartitioner(StreamPartitioner<? super K, ? super V>) - Static method in class org.apache.kafka.streams.kstream.Produced
-
Create a Produced instance with provided partitioner.
- streamPartitioner(StreamPartitioner<K, V>) - Static method in class org.apache.kafka.streams.kstream.Repartitioned
-
Create a Repartitioned
instance with provided partitioner.
- StreamPartitioner<K,V> - Interface in org.apache.kafka.streams.processor
-
Determine how records are distributed among the partitions in a Kafka topic.
- StreamsBuilder - Class in org.apache.kafka.streams
-
StreamsBuilder
provide the high-level Kafka Streams DSL to specify a Kafka Streams topology.
- StreamsBuilder() - Constructor for class org.apache.kafka.streams.StreamsBuilder
-
- StreamsConfig - Class in org.apache.kafka.streams
-
- StreamsConfig(Map<?, ?>) - Constructor for class org.apache.kafka.streams.StreamsConfig
-
Create a new StreamsConfig
using the given properties.
- StreamsConfig(Map<?, ?>, boolean) - Constructor for class org.apache.kafka.streams.StreamsConfig
-
- StreamsConfig.InternalConfig - Class in org.apache.kafka.streams
-
- StreamsException - Exception in org.apache.kafka.streams.errors
-
StreamsException
is the top-level exception type generated by Kafka Streams, and indicates errors have
occurred during a
StreamThread's
processing.
- StreamsException(String) - Constructor for exception org.apache.kafka.streams.errors.StreamsException
-
- StreamsException(String, TaskId) - Constructor for exception org.apache.kafka.streams.errors.StreamsException
-
- StreamsException(String, Throwable) - Constructor for exception org.apache.kafka.streams.errors.StreamsException
-
- StreamsException(String, Throwable, TaskId) - Constructor for exception org.apache.kafka.streams.errors.StreamsException
-
- StreamsException(Throwable) - Constructor for exception org.apache.kafka.streams.errors.StreamsException
-
- StreamsException(Throwable, TaskId) - Constructor for exception org.apache.kafka.streams.errors.StreamsException
-
- StreamsMetadata - Class in org.apache.kafka.streams.state
-
- StreamsMetadata(HostInfo, Set<String>, Set<TopicPartition>, Set<String>, Set<TopicPartition>) - Constructor for class org.apache.kafka.streams.state.StreamsMetadata
-
Deprecated.
- StreamsMetadata - Interface in org.apache.kafka.streams
-
Metadata of a Kafka Streams client.
- streamsMetadataForStore(String) - Method in class org.apache.kafka.streams.KafkaStreams
-
Find all currently running
KafkaStreams
instances (potentially remotely) that
use the same
application ID
as this instance (i.e., all
instances that belong to the same Kafka Streams application)
and that contain a
StateStore
with the given
storeName
and return
StreamsMetadata
for each discovered instance.
- StreamsMetrics - Interface in org.apache.kafka.streams
-
The Kafka Streams metrics interface for adding metric sensors and collecting metric values.
- StreamsNotStartedException - Exception in org.apache.kafka.streams.errors
-
Indicates that Kafka Streams is in state
CREATED
and thus state stores cannot be queries yet.
- StreamsNotStartedException(String) - Constructor for exception org.apache.kafka.streams.errors.StreamsNotStartedException
-
- StreamsNotStartedException(String, Throwable) - Constructor for exception org.apache.kafka.streams.errors.StreamsNotStartedException
-
- StreamsRebalancingException - Exception in org.apache.kafka.streams.errors
-
Indicates that Kafka Streams is in state
REBALANCING
and thus
cannot be queried by default.
- StreamsRebalancingException(String) - Constructor for exception org.apache.kafka.streams.errors.StreamsRebalancingException
-
- StreamsRebalancingException(String, Throwable) - Constructor for exception org.apache.kafka.streams.errors.StreamsRebalancingException
-
- StreamsUncaughtExceptionHandler - Interface in org.apache.kafka.streams.errors
-
- StreamsUncaughtExceptionHandler.StreamThreadExceptionResponse - Enum in org.apache.kafka.streams.errors
-
Enumeration that describes the response from the exception handler.
- subtopologies() - Method in interface org.apache.kafka.streams.TopologyDescription
-
All sub-topologies of the represented topology.
- subtopology() - Method in class org.apache.kafka.streams.processor.TaskId
-
- successors() - Method in interface org.apache.kafka.streams.TopologyDescription.Node
-
The successor of this node within a sub-topology.
- suppress(Suppressed<? super K>) - Method in interface org.apache.kafka.streams.kstream.KTable
-
Suppress some updates from this changelog stream, determined by the supplied
Suppressed
configuration.
- Suppressed<K> - Interface in org.apache.kafka.streams.kstream
-
- Suppressed.BufferConfig<BC extends Suppressed.BufferConfig<BC>> - Interface in org.apache.kafka.streams.kstream
-
- Suppressed.EagerBufferConfig - Interface in org.apache.kafka.streams.kstream
-
Marker interface for a buffer configuration that will strictly enforce size constraints
(bytes and/or number of records) on the buffer, so it is suitable for reducing duplicate
results downstream, but does not promise to eliminate them entirely.
- Suppressed.StrictBufferConfig - Interface in org.apache.kafka.streams.kstream
-
Marker interface for a buffer configuration that is "strict" in the sense that it will strictly
enforce the time bound and never emit early.
- table(String, Consumed<K, V>, Materialized<K, V, KeyValueStore<Bytes, byte[]>>) - Method in class org.apache.kafka.streams.StreamsBuilder
-
Create a
KTable
for the specified topic.
- table(String) - Method in class org.apache.kafka.streams.StreamsBuilder
-
Create a
KTable
for the specified topic.
- table(String, Consumed<K, V>) - Method in class org.apache.kafka.streams.StreamsBuilder
-
Create a
KTable
for the specified topic.
- table(String, Materialized<K, V, KeyValueStore<Bytes, byte[]>>) - Method in class org.apache.kafka.streams.StreamsBuilder
-
Create a
KTable
for the specified topic.
- TableJoined<K,KO> - Class in org.apache.kafka.streams.kstream
-
- TableJoined(TableJoined<K, KO>) - Constructor for class org.apache.kafka.streams.kstream.TableJoined
-
- TASK_TIMEOUT_MS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
task.timeout.ms
- TASK_TIMEOUT_MS_DOC - Static variable in class org.apache.kafka.streams.StreamsConfig
-
- TaskAssignmentException - Exception in org.apache.kafka.streams.errors
-
Indicates a run time error incurred while trying to assign
stream tasks
to
threads
.
- TaskAssignmentException(String) - Constructor for exception org.apache.kafka.streams.errors.TaskAssignmentException
-
- TaskAssignmentException(String, Throwable) - Constructor for exception org.apache.kafka.streams.errors.TaskAssignmentException
-
- TaskAssignmentException(Throwable) - Constructor for exception org.apache.kafka.streams.errors.TaskAssignmentException
-
- TaskCorruptedException - Exception in org.apache.kafka.streams.errors
-
Indicates a specific task is corrupted and need to be re-initialized.
- TaskCorruptedException(Set<TaskId>) - Constructor for exception org.apache.kafka.streams.errors.TaskCorruptedException
-
- TaskCorruptedException(Set<TaskId>, InvalidOffsetException) - Constructor for exception org.apache.kafka.streams.errors.TaskCorruptedException
-
- taskId() - Method in exception org.apache.kafka.streams.errors.StreamsException
-
- taskId() - Method in interface org.apache.kafka.streams.processor.api.ProcessorContext
-
Return the task id.
- taskId() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
-
Return the task id.
- taskId() - Method in interface org.apache.kafka.streams.processor.StateStoreContext
-
Returns the task id.
- TaskId - Class in org.apache.kafka.streams.processor
-
The task ID representation composed as subtopology (aka topicGroupId) plus the assigned partition ID.
- TaskId(int, int) - Constructor for class org.apache.kafka.streams.processor.TaskId
-
- TaskId(int, int, String) - Constructor for class org.apache.kafka.streams.processor.TaskId
-
- taskId() - Method in class org.apache.kafka.streams.processor.TaskMetadata
-
Deprecated.
- taskId() - Method in interface org.apache.kafka.streams.TaskMetadata
-
Task ID of the task.
- TaskIdFormatException - Exception in org.apache.kafka.streams.errors
-
Indicates a run time error incurred while trying parse the
task id
from the read string.
- TaskIdFormatException(String) - Constructor for exception org.apache.kafka.streams.errors.TaskIdFormatException
-
- TaskIdFormatException(String, Throwable) - Constructor for exception org.apache.kafka.streams.errors.TaskIdFormatException
-
- TaskIdFormatException(Throwable) - Constructor for exception org.apache.kafka.streams.errors.TaskIdFormatException
-
- TaskMetadata - Class in org.apache.kafka.streams.processor
-
- TaskMetadata(String, Set<TopicPartition>, Map<TopicPartition, Long>, Map<TopicPartition, Long>, Optional<Long>) - Constructor for class org.apache.kafka.streams.processor.TaskMetadata
-
Deprecated.
- TaskMetadata - Interface in org.apache.kafka.streams
-
Metadata of a task.
- TaskMigratedException - Exception in org.apache.kafka.streams.errors
-
Indicates that all tasks belongs to the thread have migrated to another thread.
- TaskMigratedException(String) - Constructor for exception org.apache.kafka.streams.errors.TaskMigratedException
-
- TaskMigratedException(String, Throwable) - Constructor for exception org.apache.kafka.streams.errors.TaskMigratedException
-
- test(K, V) - Method in interface org.apache.kafka.streams.kstream.Predicate
-
Test if the record with the given key and value satisfies the predicate.
- thisStoreSupplier - Variable in class org.apache.kafka.streams.kstream.StreamJoined
-
- ThreadMetadata - Class in org.apache.kafka.streams.processor
-
- ThreadMetadata(String, String, String, String, Set<String>, String, Set<TaskMetadata>, Set<TaskMetadata>) - Constructor for class org.apache.kafka.streams.processor.ThreadMetadata
-
Deprecated.
- ThreadMetadata - Interface in org.apache.kafka.streams
-
Metadata of a stream thread.
- threadName() - Method in class org.apache.kafka.streams.processor.ThreadMetadata
-
Deprecated.
- threadName() - Method in interface org.apache.kafka.streams.ThreadMetadata
-
Name of the stream thread
- threads - Variable in class org.apache.kafka.streams.KafkaStreams
-
- threadState() - Method in class org.apache.kafka.streams.processor.ThreadMetadata
-
Deprecated.
- threadState() - Method in interface org.apache.kafka.streams.ThreadMetadata
-
State of the stream thread
- through(String) - Method in interface org.apache.kafka.streams.kstream.KStream
-
- through(String, Produced<K, V>) - Method in interface org.apache.kafka.streams.kstream.KStream
-
- timeCurrentIdlingStarted() - Method in class org.apache.kafka.streams.processor.TaskMetadata
-
Deprecated.
This function will return the time task idling started, if the task is not currently idling it will return empty
- timeCurrentIdlingStarted() - Method in interface org.apache.kafka.streams.TaskMetadata
-
Time task idling started.
- timeDifferenceMs() - Method in class org.apache.kafka.streams.kstream.SlidingWindows
-
- timestamp() - Method in class org.apache.kafka.streams.processor.api.Record
-
The timestamp of the record.
- timestamp() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
-
Return the current timestamp.
- timestamp() - Method in interface org.apache.kafka.streams.processor.RecordContext
-
Return the current timestamp.
- timestamp - Variable in class org.apache.kafka.streams.processor.To
-
- timestamp() - Method in class org.apache.kafka.streams.state.ValueAndTimestamp
-
- TIMESTAMP_SIZE - Static variable in class org.apache.kafka.streams.state.StateSerdes
-
- TimestampedBytesStore - Interface in org.apache.kafka.streams.state
-
- timestampedKeyValueStore() - Static method in class org.apache.kafka.streams.state.QueryableStoreTypes
-
- TimestampedKeyValueStore<K,V> - Interface in org.apache.kafka.streams.state
-
A key-(value/timestamp) store that supports put/get/delete and range queries.
- timestampedKeyValueStoreBuilder(KeyValueBytesStoreSupplier, Serde<K>, Serde<V>) - Static method in class org.apache.kafka.streams.state.Stores
-
- timestampedWindowStore() - Static method in class org.apache.kafka.streams.state.QueryableStoreTypes
-
- TimestampedWindowStore<K,V> - Interface in org.apache.kafka.streams.state
-
Interface for storing the aggregated values of fixed-size time windows.
- timestampedWindowStoreBuilder(WindowBytesStoreSupplier, Serde<K>, Serde<V>) - Static method in class org.apache.kafka.streams.state.Stores
-
- timestampExtractor - Variable in class org.apache.kafka.streams.kstream.Consumed
-
- TimestampExtractor - Interface in org.apache.kafka.streams.processor
-
An interface that allows the Kafka Streams framework to extract a timestamp from an instance of ConsumerRecord
.
- TimeWindowedCogroupedKStream<K,V> - Interface in org.apache.kafka.streams.kstream
-
TimeWindowedCogroupKStream
is an abstraction of a
windowed record stream of
KeyValue
pairs.
- TimeWindowedDeserializer<T> - Class in org.apache.kafka.streams.kstream
-
- TimeWindowedDeserializer() - Constructor for class org.apache.kafka.streams.kstream.TimeWindowedDeserializer
-
- TimeWindowedDeserializer(Deserializer<T>) - Constructor for class org.apache.kafka.streams.kstream.TimeWindowedDeserializer
-
Deprecated.
- TimeWindowedDeserializer(Deserializer<T>, Long) - Constructor for class org.apache.kafka.streams.kstream.TimeWindowedDeserializer
-
- TimeWindowedKStream<K,V> - Interface in org.apache.kafka.streams.kstream
-
TimeWindowedKStream
is an abstraction of a
windowed record stream of
KeyValue
pairs.
- TimeWindowedSerde() - Constructor for class org.apache.kafka.streams.kstream.WindowedSerdes.TimeWindowedSerde
-
- TimeWindowedSerde(Serde<T>) - Constructor for class org.apache.kafka.streams.kstream.WindowedSerdes.TimeWindowedSerde
-
Deprecated.
- TimeWindowedSerde(Serde<T>, long) - Constructor for class org.apache.kafka.streams.kstream.WindowedSerdes.TimeWindowedSerde
-
- timeWindowedSerdeFrom(Class<T>) - Static method in class org.apache.kafka.streams.kstream.WindowedSerdes
-
Deprecated.
- timeWindowedSerdeFrom(Class<T>, long) - Static method in class org.apache.kafka.streams.kstream.WindowedSerdes
-
Construct a TimeWindowedSerde
object to deserialize changelog topic
for the specified inner class type and window size.
- TimeWindowedSerializer<T> - Class in org.apache.kafka.streams.kstream
-
- TimeWindowedSerializer() - Constructor for class org.apache.kafka.streams.kstream.TimeWindowedSerializer
-
- TimeWindowedSerializer(Serializer<T>) - Constructor for class org.apache.kafka.streams.kstream.TimeWindowedSerializer
-
- TimeWindows - Class in org.apache.kafka.streams.kstream
-
The fixed-size time-based window specifications used for aggregations.
- to(String) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Materialize this stream to a topic using default serializers specified in the config and producer's
DefaultPartitioner
.
- to(String, Produced<K, V>) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Materialize this stream to a topic using the provided
Produced
instance.
- to(TopicNameExtractor<K, V>) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Dynamically materialize this stream to topics using default serializers specified in the config and producer's
DefaultPartitioner
.
- to(TopicNameExtractor<K, V>, Produced<K, V>) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Dynamically materialize this stream to topics using the provided
Produced
instance.
- To - Class in org.apache.kafka.streams.processor
-
- To(To) - Constructor for class org.apache.kafka.streams.processor.To
-
- toFile(String) - Static method in class org.apache.kafka.streams.kstream.Printed
-
Print the records of a
KStream
to a file.
- topic() - Method in interface org.apache.kafka.streams.processor.api.RecordMetadata
-
Return the topic name of the current input record; could be null
if it is not
available.
- topic() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
-
Return the topic name of the current input record; could be null
if it is not
available.
- topic() - Method in interface org.apache.kafka.streams.processor.RecordContext
-
Return the topic name of the current input record; could be null
if it is not
available.
- topic() - Method in class org.apache.kafka.streams.state.StateSerdes
-
Return the topic.
- topic() - Method in interface org.apache.kafka.streams.TopologyDescription.Sink
-
The topic name this sink node is writing to.
- TOPIC_PREFIX - Static variable in class org.apache.kafka.streams.StreamsConfig
-
Prefix used to provide default topic configs to be applied when creating internal topics.
- topicConfig - Variable in class org.apache.kafka.streams.kstream.Materialized
-
- topicConfig - Variable in class org.apache.kafka.streams.kstream.StreamJoined
-
- topicGroupId - Variable in class org.apache.kafka.streams.processor.TaskId
-
Deprecated.
- TopicNameExtractor<K,V> - Interface in org.apache.kafka.streams.processor
-
An interface that allows to dynamically determine the name of the Kafka topic to send at the sink node of the topology.
- topicNameExtractor() - Method in interface org.apache.kafka.streams.TopologyDescription.Sink
-
The
TopicNameExtractor
class that this sink node uses to dynamically extract the topic name to write to.
- topicPartitions() - Method in class org.apache.kafka.streams.processor.TaskMetadata
-
Deprecated.
- topicPartitions() - Method in class org.apache.kafka.streams.state.StreamsMetadata
-
Deprecated.
Topic partitions consumed by the instance as an active replica
- topicPartitions() - Method in interface org.apache.kafka.streams.StreamsMetadata
-
Source topic partitions of the active tasks of the Streams client.
- topicPartitions() - Method in interface org.apache.kafka.streams.TaskMetadata
-
Source topic partitions of the task.
- topicPattern() - Method in interface org.apache.kafka.streams.TopologyDescription.Source
-
The pattern used to match topic names that is reading from.
- topicPrefix(String) - Static method in class org.apache.kafka.streams.StreamsConfig
-
Prefix a property with
StreamsConfig.TOPIC_PREFIX
used to provide default topic configs to be applied when creating internal topics.
- topicSet() - Method in interface org.apache.kafka.streams.TopologyDescription.Source
-
The topic names this source node is reading from.
- topology - Variable in class org.apache.kafka.streams.StreamsBuilder
-
The actual topology that is constructed by this StreamsBuilder.
- Topology - Class in org.apache.kafka.streams
-
A logical representation of a ProcessorTopology
.
- Topology() - Constructor for class org.apache.kafka.streams.Topology
-
- Topology.AutoOffsetReset - Enum in org.apache.kafka.streams
-
- TOPOLOGY_OPTIMIZATION - Static variable in class org.apache.kafka.streams.StreamsConfig
-
- TOPOLOGY_OPTIMIZATION_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
topology.optimization
- TopologyDescription - Interface in org.apache.kafka.streams
-
- TopologyDescription.GlobalStore - Interface in org.apache.kafka.streams
-
- TopologyDescription.Node - Interface in org.apache.kafka.streams
-
A node of a topology.
- TopologyDescription.Processor - Interface in org.apache.kafka.streams
-
A processor node of a topology.
- TopologyDescription.Sink - Interface in org.apache.kafka.streams
-
A sink node of a topology.
- TopologyDescription.Source - Interface in org.apache.kafka.streams
-
A source node of a topology.
- TopologyDescription.Subtopology - Interface in org.apache.kafka.streams
-
- TopologyException - Exception in org.apache.kafka.streams.errors
-
Indicates a pre run time error occurred while parsing the
logical topology
to construct the
physical processor topology
.
- TopologyException(String) - Constructor for exception org.apache.kafka.streams.errors.TopologyException
-
- TopologyException(String, Throwable) - Constructor for exception org.apache.kafka.streams.errors.TopologyException
-
- TopologyException(Throwable) - Constructor for exception org.apache.kafka.streams.errors.TopologyException
-
- topologyMetadata - Variable in class org.apache.kafka.streams.KafkaStreams
-
- topologyName() - Method in class org.apache.kafka.streams.processor.TaskId
-
Experimental feature -- will return null
- toStream() - Method in interface org.apache.kafka.streams.kstream.KTable
-
Convert this changelog stream to a
KStream
.
- toStream(Named) - Method in interface org.apache.kafka.streams.kstream.KTable
-
Convert this changelog stream to a
KStream
.
- toStream(KeyValueMapper<? super K, ? super V, ? extends KR>) - Method in interface org.apache.kafka.streams.kstream.KTable
-
- toStream(KeyValueMapper<? super K, ? super V, ? extends KR>, Named) - Method in interface org.apache.kafka.streams.kstream.KTable
-
- toString() - Method in class org.apache.kafka.streams.KeyQueryMetadata
-
- toString() - Method in class org.apache.kafka.streams.KeyValue
-
- toString() - Method in class org.apache.kafka.streams.kstream.JoinWindows
-
- toString() - Method in class org.apache.kafka.streams.kstream.SessionWindows
-
- toString() - Method in class org.apache.kafka.streams.kstream.SlidingWindows
-
- toString() - Method in class org.apache.kafka.streams.kstream.StreamJoined
-
- toString() - Method in class org.apache.kafka.streams.kstream.TimeWindows
-
- toString() - Method in class org.apache.kafka.streams.kstream.UnlimitedWindows
-
- toString() - Method in class org.apache.kafka.streams.kstream.Window
-
- toString() - Method in class org.apache.kafka.streams.kstream.Windowed
-
- toString() - Method in class org.apache.kafka.streams.LagInfo
-
- toString() - Method in class org.apache.kafka.streams.processor.api.Record
-
- toString() - Method in class org.apache.kafka.streams.processor.TaskId
-
- toString() - Method in class org.apache.kafka.streams.processor.TaskMetadata
-
Deprecated.
- toString() - Method in class org.apache.kafka.streams.processor.ThreadMetadata
-
Deprecated.
- toString() - Method in class org.apache.kafka.streams.processor.To
-
- toString() - Method in class org.apache.kafka.streams.state.HostInfo
-
- toString() - Method in class org.apache.kafka.streams.state.StreamsMetadata
-
Deprecated.
- toString() - Method in class org.apache.kafka.streams.state.ValueAndTimestamp
-
- toString() - Method in class org.apache.kafka.streams.StoreQueryParameters
-
- toSysOut() - Static method in class org.apache.kafka.streams.kstream.Printed
-
Print the records of a
KStream
to system out.
- toTable() - Method in interface org.apache.kafka.streams.kstream.KStream
-
Convert this stream to a
KTable
.
- toTable(Named) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Convert this stream to a
KTable
.
- toTable(Materialized<K, V, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Convert this stream to a
KTable
.
- toTable(Named, Materialized<K, V, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Convert this stream to a
KTable
.
- transform(TransformerSupplier<? super K, ? super V, KeyValue<K1, V1>>, String...) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Transform each record of the input stream into zero or one record in the output stream (both key and value type
can be altered arbitrarily).
- transform(TransformerSupplier<? super K, ? super V, KeyValue<K1, V1>>, Named, String...) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Transform each record of the input stream into zero or one record in the output stream (both key and value type
can be altered arbitrarily).
- transform(K, V) - Method in interface org.apache.kafka.streams.kstream.Transformer
-
Transform the record with the given key and value.
- transform(V) - Method in interface org.apache.kafka.streams.kstream.ValueTransformer
-
Transform the given value to a new value.
- transform(K, V) - Method in interface org.apache.kafka.streams.kstream.ValueTransformerWithKey
-
Transform the given [key and] value to a new value.
- Transformer<K,V,R> - Interface in org.apache.kafka.streams.kstream
-
The Transformer
interface is for stateful mapping of an input record to zero, one, or multiple new output
records (both key and value type can be altered arbitrarily).
- TransformerSupplier<K,V,R> - Interface in org.apache.kafka.streams.kstream
-
A
TransformerSupplier
interface which can create one or more
Transformer
instances.
- transformValues(ValueTransformerSupplier<? super V, ? extends VR>, String...) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Transform the value of each input record into a new value (with possibly a new type) of the output record.
- transformValues(ValueTransformerSupplier<? super V, ? extends VR>, Named, String...) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Transform the value of each input record into a new value (with possibly a new type) of the output record.
- transformValues(ValueTransformerWithKeySupplier<? super K, ? super V, ? extends VR>, String...) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Transform the value of each input record into a new value (with possibly a new type) of the output record.
- transformValues(ValueTransformerWithKeySupplier<? super K, ? super V, ? extends VR>, Named, String...) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Transform the value of each input record into a new value (with possibly a new type) of the output record.
- transformValues(ValueTransformerWithKeySupplier<? super K, ? super V, ? extends VR>, String...) - Method in interface org.apache.kafka.streams.kstream.KTable
-
Create a new KTable
by transforming the value of each record in this KTable
into a new value
(with possibly a new type), with default serializers, deserializers, and state store.
- transformValues(ValueTransformerWithKeySupplier<? super K, ? super V, ? extends VR>, Named, String...) - Method in interface org.apache.kafka.streams.kstream.KTable
-
Create a new KTable
by transforming the value of each record in this KTable
into a new value
(with possibly a new type), with default serializers, deserializers, and state store.
- transformValues(ValueTransformerWithKeySupplier<? super K, ? super V, ? extends VR>, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>, String...) - Method in interface org.apache.kafka.streams.kstream.KTable
-
Create a new
KTable
by transforming the value of each record in this
KTable
into a new value
(with possibly a new type), with the
key serde
,
value serde
, and the underlying
materialized state storage
configured in the
Materialized
instance.
- transformValues(ValueTransformerWithKeySupplier<? super K, ? super V, ? extends VR>, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>, Named, String...) - Method in interface org.apache.kafka.streams.kstream.KTable
-
Create a new
KTable
by transforming the value of each record in this
KTable
into a new value
(with possibly a new type), with the
key serde
,
value serde
, and the underlying
materialized state storage
configured in the
Materialized
instance.
- validate(String) - Static method in class org.apache.kafka.streams.kstream.Named
-
- value - Variable in class org.apache.kafka.streams.KeyValue
-
The value of the key-value pair.
- value() - Method in class org.apache.kafka.streams.processor.api.Record
-
The value of the record.
- value() - Method in class org.apache.kafka.streams.state.ValueAndTimestamp
-
- ValueAndTimestamp<V> - Class in org.apache.kafka.streams.state
-
Combines a value from a
KeyValue
with a timestamp.
- valueDeserializer() - Method in class org.apache.kafka.streams.state.StateSerdes
-
Return the value deserializer.
- valueFrom(byte[]) - Method in class org.apache.kafka.streams.state.StateSerdes
-
Deserialize the value from raw bytes.
- ValueJoiner<V1,V2,VR> - Interface in org.apache.kafka.streams.kstream
-
The ValueJoiner
interface for joining two values into a new value of arbitrary type.
- ValueJoinerWithKey<K1,V1,V2,VR> - Interface in org.apache.kafka.streams.kstream
-
The ValueJoinerWithKey
interface for joining two values into a new value of arbitrary type.
- ValueMapper<V,VR> - Interface in org.apache.kafka.streams.kstream
-
The ValueMapper
interface for mapping a value to a new value of arbitrary type.
- ValueMapperWithKey<K,V,VR> - Interface in org.apache.kafka.streams.kstream
-
The ValueMapperWithKey
interface for mapping a value to a new value of arbitrary type.
- valueOf(String) - Static method in enum org.apache.kafka.streams.errors.DeserializationExceptionHandler.DeserializationHandlerResponse
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.kafka.streams.errors.ProductionExceptionHandler.ProductionExceptionHandlerResponse
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.kafka.streams.errors.StreamsUncaughtExceptionHandler.StreamThreadExceptionResponse
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.kafka.streams.KafkaStreams.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.kafka.streams.processor.PunctuationType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.kafka.streams.Topology.AutoOffsetReset
-
Returns the enum constant of this type with the specified name.
- values() - Static method in enum org.apache.kafka.streams.errors.DeserializationExceptionHandler.DeserializationHandlerResponse
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.kafka.streams.errors.ProductionExceptionHandler.ProductionExceptionHandlerResponse
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.kafka.streams.errors.StreamsUncaughtExceptionHandler.StreamThreadExceptionResponse
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.kafka.streams.KafkaStreams.State
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.kafka.streams.processor.PunctuationType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.kafka.streams.Topology.AutoOffsetReset
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- valueSerde - Variable in class org.apache.kafka.streams.kstream.Consumed
-
- valueSerde - Variable in class org.apache.kafka.streams.kstream.Grouped
-
- valueSerde(Serde<V>) - Static method in class org.apache.kafka.streams.kstream.Grouped
-
Create a
Grouped
instance with the provided valueSerde.
- valueSerde - Variable in class org.apache.kafka.streams.kstream.Joined
-
- valueSerde(Serde<V>) - Static method in class org.apache.kafka.streams.kstream.Joined
-
Create an instance of Joined
with a value Serde
.
- valueSerde() - Method in class org.apache.kafka.streams.kstream.Joined
-
- valueSerde - Variable in class org.apache.kafka.streams.kstream.Materialized
-
- valueSerde - Variable in class org.apache.kafka.streams.kstream.Produced
-
- valueSerde(Serde<V>) - Static method in class org.apache.kafka.streams.kstream.Produced
-
Create a Produced instance with provided valueSerde.
- valueSerde - Variable in class org.apache.kafka.streams.kstream.Repartitioned
-
- valueSerde - Variable in class org.apache.kafka.streams.kstream.StreamJoined
-
- valueSerde() - Method in interface org.apache.kafka.streams.processor.api.ProcessorContext
-
Return the default value serde.
- valueSerde() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
-
Return the default value serde.
- valueSerde() - Method in interface org.apache.kafka.streams.processor.StateStoreContext
-
Returns the default value serde.
- valueSerde() - Method in class org.apache.kafka.streams.state.StateSerdes
-
Return the value serde.
- valueSerializer() - Method in class org.apache.kafka.streams.state.StateSerdes
-
Return the value serializer.
- ValueTransformer<V,VR> - Interface in org.apache.kafka.streams.kstream
-
The ValueTransformer
interface for stateful mapping of a value to a new value (with possible new type).
- ValueTransformerSupplier<V,VR> - Interface in org.apache.kafka.streams.kstream
-
A
ValueTransformerSupplier
interface which can create one or more
ValueTransformer
instances.
- ValueTransformerWithKey<K,V,VR> - Interface in org.apache.kafka.streams.kstream
-
The ValueTransformerWithKey
interface for stateful mapping of a value to a new value (with possible new type).
- ValueTransformerWithKeySupplier<K,V,VR> - Interface in org.apache.kafka.streams.kstream
-
- WallclockTimestampExtractor - Class in org.apache.kafka.streams.processor
-
- WallclockTimestampExtractor() - Constructor for class org.apache.kafka.streams.processor.WallclockTimestampExtractor
-
- Window - Class in org.apache.kafka.streams.kstream
-
A single window instance, defined by its start and end timestamp.
- Window(long, long) - Constructor for class org.apache.kafka.streams.kstream.Window
-
Create a new window for the given start and end time.
- window() - Method in class org.apache.kafka.streams.kstream.Windowed
-
Return the window containing the values associated with this key.
- WINDOW_SIZE_MS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
window.size.ms
- WINDOW_STORE_CHANGE_LOG_ADDITIONAL_RETENTION_MS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
windowstore.changelog.additional.retention.ms
- WindowBytesStoreSupplier - Interface in org.apache.kafka.streams.state
-
- Windowed<K> - Class in org.apache.kafka.streams.kstream
-
The result key type of a windowed stream aggregation.
- Windowed(K, Window) - Constructor for class org.apache.kafka.streams.kstream.Windowed
-
- WINDOWED_INNER_CLASS_SERDE - Static variable in class org.apache.kafka.streams.StreamsConfig
-
- windowedBy(Windows<W>) - Method in interface org.apache.kafka.streams.kstream.CogroupedKStream
-
- windowedBy(SlidingWindows) - Method in interface org.apache.kafka.streams.kstream.CogroupedKStream
-
- windowedBy(SessionWindows) - Method in interface org.apache.kafka.streams.kstream.CogroupedKStream
-
- windowedBy(Windows<W>) - Method in interface org.apache.kafka.streams.kstream.KGroupedStream
-
- windowedBy(SlidingWindows) - Method in interface org.apache.kafka.streams.kstream.KGroupedStream
-
Create a new
TimeWindowedKStream
instance that can be used to perform sliding windowed aggregations.
- windowedBy(SessionWindows) - Method in interface org.apache.kafka.streams.kstream.KGroupedStream
-
- WindowedSerdes - Class in org.apache.kafka.streams.kstream
-
- WindowedSerdes() - Constructor for class org.apache.kafka.streams.kstream.WindowedSerdes
-
- WindowedSerdes.SessionWindowedSerde<T> - Class in org.apache.kafka.streams.kstream
-
- WindowedSerdes.TimeWindowedSerde<T> - Class in org.apache.kafka.streams.kstream
-
- Windows<W extends Window> - Class in org.apache.kafka.streams.kstream
-
The window specification for fixed size windows that is used to define window boundaries and grace period.
- Windows() - Constructor for class org.apache.kafka.streams.kstream.Windows
-
- windowsFor(long) - Method in class org.apache.kafka.streams.kstream.JoinWindows
-
Not supported by JoinWindows
.
- windowsFor(long) - Method in class org.apache.kafka.streams.kstream.TimeWindows
-
- windowsFor(long) - Method in class org.apache.kafka.streams.kstream.UnlimitedWindows
-
- windowsFor(long) - Method in class org.apache.kafka.streams.kstream.Windows
-
Create all windows that contain the provided timestamp, indexed by non-negative window start timestamps.
- windowSize() - Method in interface org.apache.kafka.streams.state.WindowBytesStoreSupplier
-
The size of the windows (in milliseconds) any store created from this supplier is creating.
- windowStore() - Static method in class org.apache.kafka.streams.state.QueryableStoreTypes
-
- WindowStore<K,V> - Interface in org.apache.kafka.streams.state
-
Interface for storing the aggregated values of fixed-size time windows.
- windowStoreBuilder(WindowBytesStoreSupplier, Serde<K>, Serde<V>) - Static method in class org.apache.kafka.streams.state.Stores
-
- WindowStoreIterator<V> - Interface in org.apache.kafka.streams.state
-
- with(Serde<K>, Serde<V>, TimestampExtractor, Topology.AutoOffsetReset) - Static method in class org.apache.kafka.streams.kstream.Consumed
-
Create an instance of
Consumed
with the supplied arguments.
- with(Serde<K>, Serde<V>) - Static method in class org.apache.kafka.streams.kstream.Consumed
-
Create an instance of
Consumed
with key and value
Serde
s.
- with(TimestampExtractor) - Static method in class org.apache.kafka.streams.kstream.Consumed
-
- with(Topology.AutoOffsetReset) - Static method in class org.apache.kafka.streams.kstream.Consumed
-
- with(String, Serde<K>, Serde<V>) - Static method in class org.apache.kafka.streams.kstream.Grouped
-
Create a
Grouped
instance with the provided name, keySerde, and valueSerde.
- with(Serde<K>, Serde<V>) - Static method in class org.apache.kafka.streams.kstream.Grouped
-
Create a
Grouped
instance with the provided keySerde and valueSerde.
- with(Serde<K>, Serde<V>, Serde<VO>) - Static method in class org.apache.kafka.streams.kstream.Joined
-
Create an instance of Joined
with key, value, and otherValue Serde
instances.
- with(Serde<K>, Serde<V>, Serde<VO>, String) - Static method in class org.apache.kafka.streams.kstream.Joined
-
Create an instance of Joined
with key, value, and otherValue Serde
instances.
- with(Serde<K>, Serde<V>) - Static method in class org.apache.kafka.streams.kstream.Materialized
-
Materialize a
StateStore
with the provided key and value
Serde
s.
- with(Serde<K>, Serde<V>) - Static method in class org.apache.kafka.streams.kstream.Produced
-
Create a Produced instance with provided keySerde and valueSerde.
- with(Serde<K>, Serde<V>, StreamPartitioner<? super K, ? super V>) - Static method in class org.apache.kafka.streams.kstream.Produced
-
Create a Produced instance with provided keySerde, valueSerde, and partitioner.
- with(Serde<K>, Serde<V>) - Static method in class org.apache.kafka.streams.kstream.Repartitioned
-
Create a Repartitioned
instance with provided key serde and value serde.
- with(Duration) - Static method in class org.apache.kafka.streams.kstream.SessionWindows
-
- with(WindowBytesStoreSupplier, WindowBytesStoreSupplier) - Static method in class org.apache.kafka.streams.kstream.StreamJoined
-
Creates a StreamJoined instance with the provided store suppliers.
- with(Serde<K>, Serde<V1>, Serde<V2>) - Static method in class org.apache.kafka.streams.kstream.StreamJoined
-
Creates a
StreamJoined
instance with the provided serdes to configure the stores
for the join.
- with(StreamPartitioner<K, Void>, StreamPartitioner<KO, Void>) - Static method in class org.apache.kafka.streams.kstream.TableJoined
-
Create an instance of
TableJoined
with partitioner and otherPartitioner
StreamPartitioner
instances.
- withBuiltinTypes(String, Class<K>, Class<V>) - Static method in class org.apache.kafka.streams.state.StateSerdes
-
Create a new instance of
StateSerdes
for the given state name and key-/value-type classes.
- withCachingDisabled() - Method in class org.apache.kafka.streams.kstream.Materialized
-
- withCachingDisabled() - Method in interface org.apache.kafka.streams.state.StoreBuilder
-
Disable caching on the store.
- withCachingEnabled() - Method in class org.apache.kafka.streams.kstream.Materialized
-
- withCachingEnabled() - Method in interface org.apache.kafka.streams.state.StoreBuilder
-
Enable caching on the store.
- withConsumer(Consumer<KStream<K, V>>) - Static method in class org.apache.kafka.streams.kstream.Branched
-
Create an instance of Branched
with provided chain consumer.
- withConsumer(Consumer<? super KStream<K, V>>, String) - Static method in class org.apache.kafka.streams.kstream.Branched
-
Create an instance of Branched
with provided chain consumer and branch name suffix.
- withFunction(Function<? super KStream<K, V>, ? extends KStream<K, V>>) - Static method in class org.apache.kafka.streams.kstream.Branched
-
Create an instance of Branched
with provided chain function.
- withFunction(Function<? super KStream<K, V>, ? extends KStream<K, V>>, String) - Static method in class org.apache.kafka.streams.kstream.Branched
-
Create an instance of Branched
with provided chain function and branch name suffix.
- withHeaders(Headers) - Method in class org.apache.kafka.streams.processor.api.Record
-
A convenient way to produce a new record if you only need to change the headers.
- withKey(NewK) - Method in class org.apache.kafka.streams.processor.api.Record
-
A convenient way to produce a new record if you only need to change the key.
- withKeySerde(Serde<K>) - Method in class org.apache.kafka.streams.kstream.Consumed
-
Configure the instance of
Consumed
with a key
Serde
.
- withKeySerde(Serde<K>) - Method in class org.apache.kafka.streams.kstream.Grouped
-
Perform the grouping operation using the provided keySerde for serializing the key.
- withKeySerde(Serde<K>) - Method in class org.apache.kafka.streams.kstream.Joined
-
Set the key Serde
to be used.
- withKeySerde(Serde<K>) - Method in class org.apache.kafka.streams.kstream.Materialized
-
Set the keySerde the materialize
StateStore
will use.
- withKeySerde(Serde<K>) - Method in class org.apache.kafka.streams.kstream.Produced
-
Produce records using the provided keySerde.
- withKeySerde(Serde<K>) - Method in class org.apache.kafka.streams.kstream.Repartitioned
-
Create a new instance of Repartitioned
with the provided key serde.
- withKeySerde(Serde<K>) - Method in class org.apache.kafka.streams.kstream.StreamJoined
-
Configure with the provided Serde
for the key
- withKeyValueMapper(KeyValueMapper<? super K, ? super V, String>) - Method in class org.apache.kafka.streams.kstream.Printed
-
Print the records of a
KStream
with the provided
KeyValueMapper
The provided KeyValueMapper's mapped value type must be
String
.
- withLabel(String) - Method in class org.apache.kafka.streams.kstream.Printed
-
Print the records of a
KStream
with the provided label.
- withLoggingDisabled() - Method in class org.apache.kafka.streams.kstream.Materialized
-
Disable change logging for the materialized
StateStore
.
- withLoggingDisabled() - Method in class org.apache.kafka.streams.kstream.StreamJoined
-
Disable change logging for both state stores.
- withLoggingDisabled() - Method in interface org.apache.kafka.streams.kstream.Suppressed.BufferConfig
-
Disable the changelog for this suppression's internal buffer.
- withLoggingDisabled() - Method in interface org.apache.kafka.streams.state.StoreBuilder
-
- withLoggingEnabled(Map<String, String>) - Method in class org.apache.kafka.streams.kstream.Materialized
-
Indicates that a changelog should be created for the store.
- withLoggingEnabled(Map<String, String>) - Method in class org.apache.kafka.streams.kstream.StreamJoined
-
Configures logging for both state stores.
- withLoggingEnabled(Map<String, String>) - Method in interface org.apache.kafka.streams.kstream.Suppressed.BufferConfig
-
Indicates that a changelog topic should be created containing the currently suppressed
records.
- withLoggingEnabled(Map<String, String>) - Method in interface org.apache.kafka.streams.state.StoreBuilder
-
Maintain a changelog for any changes made to the store.
- withMaxBytes(long) - Method in interface org.apache.kafka.streams.kstream.Suppressed.BufferConfig
-
Set a size constraint on the buffer, the maximum number of bytes it will use.
- withMaxRecords(long) - Method in interface org.apache.kafka.streams.kstream.Suppressed.BufferConfig
-
Set a size constraint on the buffer in terms of the maximum number of keys it will store.
- withName(String) - Method in class org.apache.kafka.streams.kstream.Branched
-
Configure the instance of Branched
with a branch name suffix.
- withName(String) - Method in class org.apache.kafka.streams.kstream.Consumed
-
Configure the instance of
Consumed
with a processor name.
- withName(String) - Method in class org.apache.kafka.streams.kstream.Grouped
-
Perform the grouping operation with the name for a repartition topic if required.
- withName(String) - Method in class org.apache.kafka.streams.kstream.Joined
-
Set the base name used for all components of the join, this may include any repartition topics
created to complete the join.
- withName(String) - Method in class org.apache.kafka.streams.kstream.Named
-
- withName(String) - Method in class org.apache.kafka.streams.kstream.Printed
-
Print the records of a
KStream
with provided processor name.
- withName(String) - Method in class org.apache.kafka.streams.kstream.Produced
-
- withName(String) - Method in class org.apache.kafka.streams.kstream.Repartitioned
-
Create a new instance of Repartitioned
with the provided name used as part of repartition topic and processor name.
- withName(String) - Method in class org.apache.kafka.streams.kstream.StreamJoined
-
Set the name to use for the join processor and the repartition topic(s) if required.
- withName(String) - Method in interface org.apache.kafka.streams.kstream.Suppressed
-
Use the specified name for the suppression node in the topology.
- withName(String) - Method in class org.apache.kafka.streams.kstream.TableJoined
-
Set the base name used for all components of the join, including internal topics
created to complete the join.
- withNoBound() - Method in interface org.apache.kafka.streams.kstream.Suppressed.BufferConfig
-
Set the buffer to be unconstrained by size (either keys or bytes).
- withNumberOfPartitions(int) - Method in class org.apache.kafka.streams.kstream.Repartitioned
-
Create a new instance of Repartitioned
with the provided number of partitions for repartition topic.
- withOffsetResetPolicy(Topology.AutoOffsetReset) - Method in class org.apache.kafka.streams.kstream.Consumed
-
- withOtherPartitioner(StreamPartitioner<KO, Void>) - Method in class org.apache.kafka.streams.kstream.TableJoined
-
- withOtherStoreSupplier(WindowBytesStoreSupplier) - Method in class org.apache.kafka.streams.kstream.StreamJoined
-
- withOtherValueSerde(Serde<VO>) - Method in class org.apache.kafka.streams.kstream.Joined
-
Set the otherValue Serde
to be used.
- withOtherValueSerde(Serde<V2>) - Method in class org.apache.kafka.streams.kstream.StreamJoined
-
Configure with the provided Serde
for the other value
- withPartition(Integer) - Method in class org.apache.kafka.streams.StoreQueryParameters
-
Set a specific partition that should be queried exclusively.
- withPartitioner(StreamPartitioner<K, Void>) - Method in class org.apache.kafka.streams.kstream.TableJoined
-
- withRetention(Duration) - Method in class org.apache.kafka.streams.kstream.Materialized
-
Configure retention period for window and session stores.
- withStoreName(String) - Method in class org.apache.kafka.streams.kstream.StreamJoined
-
Sets the base store name to use for both sides of the join.
- withStreamPartitioner(StreamPartitioner<? super K, ? super V>) - Method in class org.apache.kafka.streams.kstream.Produced
-
Produce records using the provided partitioner.
- withStreamPartitioner(StreamPartitioner<K, V>) - Method in class org.apache.kafka.streams.kstream.Repartitioned
-
Create a new instance of Repartitioned
with the provided partitioner.
- withThisStoreSupplier(WindowBytesStoreSupplier) - Method in class org.apache.kafka.streams.kstream.StreamJoined
-
- withTimeDifferenceAndGrace(Duration, Duration) - Static method in class org.apache.kafka.streams.kstream.SlidingWindows
-
- withTimestamp(long) - Method in class org.apache.kafka.streams.processor.api.Record
-
A convenient way to produce a new record if you only need to change the timestamp.
- withTimestamp(long) - Method in class org.apache.kafka.streams.processor.To
-
Set the timestamp of the output record.
- withTimestampExtractor(TimestampExtractor) - Method in class org.apache.kafka.streams.kstream.Consumed
-
- withValue(NewV) - Method in class org.apache.kafka.streams.processor.api.Record
-
A convenient way to produce a new record if you only need to change the value.
- withValueSerde(Serde<V>) - Method in class org.apache.kafka.streams.kstream.Consumed
-
Configure the instance of
Consumed
with a value
Serde
.
- withValueSerde(Serde<V>) - Method in class org.apache.kafka.streams.kstream.Grouped
-
Perform the grouping operation using the provided valueSerde for serializing the value.
- withValueSerde(Serde<V>) - Method in class org.apache.kafka.streams.kstream.Joined
-
Set the value Serde
to be used.
- withValueSerde(Serde<V>) - Method in class org.apache.kafka.streams.kstream.Materialized
-
Set the valueSerde the materialized
StateStore
will use.
- withValueSerde(Serde<V>) - Method in class org.apache.kafka.streams.kstream.Produced
-
Produce records using the provided valueSerde.
- withValueSerde(Serde<V>) - Method in class org.apache.kafka.streams.kstream.Repartitioned
-
Create a new instance of Repartitioned
with the provided value serde.
- withValueSerde(Serde<V1>) - Method in class org.apache.kafka.streams.kstream.StreamJoined
-
Configure with the provided Serde
for this value
- writeTo(DataOutputStream, int) - Method in class org.apache.kafka.streams.processor.TaskId
-
- writeTo(ByteBuffer, int) - Method in class org.apache.kafka.streams.processor.TaskId
-