Index
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
A
- ACCEPTABLE_RECOVERY_LAG_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
acceptable.recovery.lag
- acceptableRecoveryLag() - Method in class org.apache.kafka.streams.processor.assignment.AssignmentConfigs
-
The configured acceptable recovery lag according to
StreamsConfig.ACCEPTABLE_RECOVERY_LAG_CONFIG
- 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. - accepts(StateStore) - Method in class org.apache.kafka.streams.state.QueryableStoreTypes.KeyValueStoreType
- accepts(StateStore) - Method in class org.apache.kafka.streams.state.QueryableStoreTypes.SessionStoreType
- accepts(StateStore) - Method in class org.apache.kafka.streams.state.QueryableStoreTypes.WindowStoreType
- ACTIVE - Enum constant in enum class org.apache.kafka.streams.processor.assignment.KafkaStreamsAssignment.AssignedTask.Type
- ACTIVE_TASK_ASSIGNED_MULTIPLE_TIMES - Enum constant in enum class org.apache.kafka.streams.processor.assignment.TaskAssignor.AssignmentError
- activeHost() - Method in class org.apache.kafka.streams.KeyQueryMetadata
-
Get the active Kafka Streams instance for given key.
- activeTasks() - Method in interface org.apache.kafka.streams.ThreadMetadata
-
Metadata of the active tasks assigned to the stream thread.
- addExecutionInfo(String) - Method in interface org.apache.kafka.streams.query.QueryResult
-
Used by stores to add detailed execution information (if requested) during query execution.
- addGlobalStore(StoreBuilder<?>, String, Deserializer<KIn>, Deserializer<VIn>, String, String, ProcessorSupplier<KIn, VIn, Void, Void>) - Method in class org.apache.kafka.streams.Topology
-
Adds a global
state store
to the topology. - addGlobalStore(StoreBuilder<?>, String, Consumed<KIn, VIn>, ProcessorSupplier<KIn, VIn, Void, Void>) - Method in class org.apache.kafka.streams.StreamsBuilder
-
Adds a global
StateStore
to the 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<KIn, VIn, KOut, VOut>, String...) - Method in class org.apache.kafka.streams.Topology
- 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. - addReadOnlyStateStore(StoreBuilder<?>, String, Deserializer<KIn>, Deserializer<VIn>, String, String, ProcessorSupplier<KIn, VIn, Void, Void>) - Method in class org.apache.kafka.streams.Topology
-
Adds a read-only
state store
to the topology. - addReadOnlyStateStore(StoreBuilder<?>, String, TimestampExtractor, Deserializer<KIn>, Deserializer<VIn>, String, String, ProcessorSupplier<KIn, VIn, Void, Void>) - Method in class org.apache.kafka.streams.Topology
- addResult(int, QueryResult<R>) - Method in class org.apache.kafka.streams.query.StateQueryResult
-
Set the result for a partitioned store query.
- 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 sink that sends records from upstream
processors
orsources
to the named Kafka topic. - addSink(String, String, Serializer<K>, Serializer<V>, String...) - Method in class org.apache.kafka.streams.Topology
- addSink(String, String, Serializer<K>, Serializer<V>, StreamPartitioner<? super K, ? super V>, String...) - Method in class org.apache.kafka.streams.Topology
- addSink(String, String, StreamPartitioner<? super K, ? super V>, String...) - Method in class org.apache.kafka.streams.Topology
- addSink(String, TopicNameExtractor<K, V>, String...) - Method in class org.apache.kafka.streams.Topology
- addSink(String, TopicNameExtractor<K, V>, Serializer<K>, Serializer<V>, String...) - Method in class org.apache.kafka.streams.Topology
- addSink(String, TopicNameExtractor<K, V>, Serializer<K>, Serializer<V>, StreamPartitioner<? super K, ? super V>, String...) - Method in class org.apache.kafka.streams.Topology
- addSink(String, TopicNameExtractor<K, V>, StreamPartitioner<? super K, ? super V>, String...) - Method in class org.apache.kafka.streams.Topology
- addSource(String, String...) - Method in class org.apache.kafka.streams.Topology
-
Add a source that consumes the named topics and forwards the records to child
processors
andsinks
. - addSource(String, Pattern) - Method in class org.apache.kafka.streams.Topology
- addSource(String, Deserializer<?>, Deserializer<?>, String...) - Method in class org.apache.kafka.streams.Topology
- addSource(String, Deserializer<?>, Deserializer<?>, Pattern) - Method in class org.apache.kafka.streams.Topology
- addSource(AutoOffsetReset, String, String...) - Method in class org.apache.kafka.streams.Topology
- addSource(AutoOffsetReset, String, Pattern) - Method in class org.apache.kafka.streams.Topology
- addSource(AutoOffsetReset, String, Deserializer<?>, Deserializer<?>, String...) - Method in class org.apache.kafka.streams.Topology
- addSource(AutoOffsetReset, String, Deserializer<?>, Deserializer<?>, Pattern) - Method in class org.apache.kafka.streams.Topology
- addSource(AutoOffsetReset, String, TimestampExtractor, Deserializer<?>, Deserializer<?>, String...) - Method in class org.apache.kafka.streams.Topology
- addSource(AutoOffsetReset, String, TimestampExtractor, Deserializer<?>, Deserializer<?>, Pattern) - Method in class org.apache.kafka.streams.Topology
- addSource(AutoOffsetReset, TimestampExtractor, String, String...) - Method in class org.apache.kafka.streams.Topology
- addSource(AutoOffsetReset, TimestampExtractor, String, Pattern) - Method in class org.apache.kafka.streams.Topology
- addSource(TimestampExtractor, String, String...) - Method in class org.apache.kafka.streams.Topology
- addSource(TimestampExtractor, String, Pattern) - Method in class org.apache.kafka.streams.Topology
- addSource(Topology.AutoOffsetReset, String, String...) - Method in class org.apache.kafka.streams.Topology
-
Deprecated.
- addSource(Topology.AutoOffsetReset, String, Pattern) - Method in class org.apache.kafka.streams.Topology
-
Deprecated.Since 4.0. Use
Topology.addSource(org.apache.kafka.streams.AutoOffsetReset, String, Pattern)
instead. - addSource(Topology.AutoOffsetReset, String, Deserializer<?>, Deserializer<?>, String...) - Method in class org.apache.kafka.streams.Topology
-
Deprecated.
- addSource(Topology.AutoOffsetReset, String, Deserializer<?>, Deserializer<?>, Pattern) - Method in class org.apache.kafka.streams.Topology
-
Deprecated.
- addSource(Topology.AutoOffsetReset, String, TimestampExtractor, Deserializer<?>, Deserializer<?>, String...) - Method in class org.apache.kafka.streams.Topology
-
Deprecated.
- addSource(Topology.AutoOffsetReset, String, TimestampExtractor, Deserializer<?>, Deserializer<?>, Pattern) - Method in class org.apache.kafka.streams.Topology
-
Deprecated.
- addSource(Topology.AutoOffsetReset, TimestampExtractor, String, String...) - Method in class org.apache.kafka.streams.Topology
-
Deprecated.
- addSource(Topology.AutoOffsetReset, TimestampExtractor, String, Pattern) - Method in class org.apache.kafka.streams.Topology
-
Deprecated.
- 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
-
Add a
state store
to the topology, and optionally connect it to one or moreprocessors
. - 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 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
-
Prefix a property with
StreamsConfig.ADMIN_CLIENT_PREFIX
. - adminInstanceId() - Method in interface org.apache.kafka.streams.ClientInstanceIds
-
Returns the
client instance id
of the admin client. - 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<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>, 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>, 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>, 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) - 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<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>, 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<VAgg>) - Method in interface org.apache.kafka.streams.kstream.CogroupedKStream
-
Aggregate the values of records in these streams by the grouped key.
- aggregate(Initializer<VAgg>, Materialized<K, VAgg, 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<VAgg>, Named) - Method in interface org.apache.kafka.streams.kstream.CogroupedKStream
-
Aggregate the values of records in these streams by the grouped key.
- aggregate(Initializer<VAgg>, Named, Materialized<K, VAgg, 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>) - 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>, Aggregator<? super K, ? super V, VR>) - Method in interface org.apache.kafka.streams.kstream.KGroupedTable
- 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(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(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(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>, 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>, 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>, 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) - 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<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>, 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>, 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, - Interface in org.apache.kafka.streams.kstreamVAgg> -
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. - allTasks() - Method in interface org.apache.kafka.streams.processor.assignment.ApplicationState
- ANY - Enum constant in enum class org.apache.kafka.streams.query.ResultOrder
- appConfigs() - Method in interface org.apache.kafka.streams.processor.api.ProcessingContext
-
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.ProcessingContext
-
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
- applicationConfigs - Variable in class org.apache.kafka.streams.TopologyConfig
- applicationId() - Method in interface org.apache.kafka.streams.processor.api.ProcessingContext
-
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.
- ApplicationState - Interface in org.apache.kafka.streams.processor.assignment
-
A read-only metadata class representing the state of the application and the current rebalance.
- apply() - Method in interface org.apache.kafka.streams.kstream.Initializer
-
Return the initial value for an aggregation.
- apply(K1, V1, V2) - Method in interface org.apache.kafka.streams.kstream.ValueJoinerWithKey
-
Return a joined value consisting of
readOnlyKey
,value1
andvalue2
. - apply(K, V) - Method in interface org.apache.kafka.streams.kstream.ForeachAction
-
Perform an action for each record of a stream.
- 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) - Method in interface org.apache.kafka.streams.kstream.ValueMapperWithKey
-
Map 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(K, V, VAgg) - 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(V) - Method in interface org.apache.kafka.streams.kstream.ValueMapper
-
Map the given value to a new value.
- apply(V1, V2) - Method in interface org.apache.kafka.streams.kstream.ValueJoiner
-
Return a joined value consisting of
value1
andvalue2
. - apply(V, V) - Method in interface org.apache.kafka.streams.kstream.Reducer
-
Aggregate the two given values into a single one.
- 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
-
Materialize a
StateStore
with the given name. - 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. - as(DslStoreSuppliers) - Static method in class org.apache.kafka.streams.kstream.Materialized
-
Materialize a
StateStore
with the givenDslStoreSuppliers
. - as(KeyValueBytesStoreSupplier) - Static method in class org.apache.kafka.streams.kstream.Materialized
-
Materialize a
KeyValueStore
using the providedKeyValueBytesStoreSupplier
. - as(SessionBytesStoreSupplier) - Static method in class org.apache.kafka.streams.kstream.Materialized
-
Materialize a
SessionStore
using the providedSessionBytesStoreSupplier
. - as(WindowBytesStoreSupplier) - Static method in class org.apache.kafka.streams.kstream.Materialized
-
Materialize a
WindowStore
using the providedWindowBytesStoreSupplier
. - ASCENDING - Enum constant in enum class org.apache.kafka.streams.query.ResultOrder
- asOf(Instant) - Method in class org.apache.kafka.streams.query.VersionedKeyQuery
-
Specifies the timestamp for the key query.
- asOfTimestamp() - Method in class org.apache.kafka.streams.query.VersionedKeyQuery
-
The timestamp of the query, if specified.
- assign(ApplicationState) - Method in class org.apache.kafka.streams.processor.assignment.assignors.StickyTaskAssignor
- assign(ApplicationState) - Method in interface org.apache.kafka.streams.processor.assignment.TaskAssignor
- AssignedTask(TaskId, KafkaStreamsAssignment.AssignedTask.Type) - Constructor for class org.apache.kafka.streams.processor.assignment.KafkaStreamsAssignment.AssignedTask
- assignment() - Method in class org.apache.kafka.streams.processor.assignment.TaskAssignor.TaskAssignment
- ASSIGNMENT_LISTENER - Static variable in class org.apache.kafka.streams.StreamsConfig.InternalConfig
- assignmentConfigs() - Method in interface org.apache.kafka.streams.processor.assignment.ApplicationState
- AssignmentConfigs - Class in org.apache.kafka.streams.processor.assignment
-
Assignment related configs for the Kafka Streams
TaskAssignor
. - AssignmentConfigs(long, int, int, long, List<String>, int, int, String) - Constructor for class org.apache.kafka.streams.processor.assignment.AssignmentConfigs
- AssignmentConfigs(long, int, int, long, List<String>, OptionalInt, OptionalInt, String) - Constructor for class org.apache.kafka.streams.processor.assignment.AssignmentConfigs
- AssignmentConfigs(Long, Integer, Integer, Long, List<String>) - Constructor for class org.apache.kafka.streams.processor.assignment.AssignmentConfigs
- assignTask(KafkaStreamsAssignment.AssignedTask) - Method in class org.apache.kafka.streams.processor.assignment.KafkaStreamsAssignment
- asWrapped(ProcessorSupplier<KIn, VIn, KOut, VOut>) - Static method in interface org.apache.kafka.streams.processor.api.ProcessorWrapper
-
Use to convert a
ProcessorSupplier
instance into aWrappedProcessorSupplier
- asWrappedFixedKey(FixedKeyProcessorSupplier<KIn, VIn, VOut>) - Static method in interface org.apache.kafka.streams.processor.api.ProcessorWrapper
-
Use to convert a
FixedKeyProcessorSupplier
instance into aWrappedFixedKeyProcessorSupplier
- at(Position) - Static method in class org.apache.kafka.streams.query.PositionBound
-
Creates a new PositionBound representing a specific position.
- AT_LEAST_ONCE - Static variable in class org.apache.kafka.streams.StreamsConfig
-
Config value for parameter
"processing.guarantee"
for at-least-once processing guarantees. - AutoOffsetReset - Class in org.apache.kafka.streams
-
Sets the
auto.offset.reset
configuration whenadding a source processor
or when creatingKStream
orKTable
viaStreamsBuilder
.
B
- backwardAll() - Method in interface org.apache.kafka.streams.state.ReadOnlyWindowStore
-
Gets all the key-value pairs in the existing windows in backward order with respect to time (from end to beginning of time).
- backwardFetch(K) - Method in interface org.apache.kafka.streams.state.ReadOnlySessionStore
-
Retrieve all aggregated sessions for the provided key.
- backwardFetch(K, long, long) - Method in interface org.apache.kafka.streams.state.WindowStore
- backwardFetch(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 in backward order with respect to time (from end to beginning of time).
- backwardFetch(K, Instant, Instant) - Method in interface org.apache.kafka.streams.state.WindowStore
- backwardFetch(K, K) - Method in interface org.apache.kafka.streams.state.ReadOnlySessionStore
-
Retrieve all aggregated sessions for the given range of keys.
- backwardFetch(K, K, long, long) - Method in interface org.apache.kafka.streams.state.WindowStore
- backwardFetch(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 in backward order with respect to time (from end to beginning of time).
- backwardFetch(K, K, Instant, Instant) - Method in interface org.apache.kafka.streams.state.WindowStore
- backwardFetchAll(long, long) - Method in interface org.apache.kafka.streams.state.WindowStore
- backwardFetchAll(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 in backward order with respect to time (from end to beginning of time).
- backwardFetchAll(Instant, Instant) - Method in interface org.apache.kafka.streams.state.WindowStore
- backwardFindSessions(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 latest to earliest.
- backwardFindSessions(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 latest to earliest.
- backwardFindSessions(K, Instant, Instant) - Method in interface org.apache.kafka.streams.state.SessionStore
- backwardFindSessions(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 latest to earliest.
- backwardFindSessions(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 latest to earliest.
- backwardFindSessions(K, K, Instant, Instant) - Method in interface org.apache.kafka.streams.state.SessionStore
- BatchingStateRestoreCallback - Interface in org.apache.kafka.streams.processor
-
Interface for batching restoration of a
StateStore
It is expected that implementations of this class will not call theStateRestoreCallback.restore(byte[], byte[])
method. - before(Duration) - Method in class org.apache.kafka.streams.kstream.JoinWindows
-
Changes the start window boundary to
timeDifference
but keep the end window boundary as is. - beforeMs - Variable in class org.apache.kafka.streams.kstream.JoinWindows
-
Maximum time difference for tuples that are before the join tuple.
- BOOLEAN_SIZE - Static variable in class org.apache.kafka.streams.state.StateSerdes
- BOOTSTRAP_SERVERS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
bootstrap.servers
- branch(Predicate<? super K, ? super V>) - Method in interface org.apache.kafka.streams.kstream.BranchedKStream
-
Define a branch for records that match the predicate.
- branch(Predicate<? super K, ? super V>, Branched<K, V>) - Method in interface org.apache.kafka.streams.kstream.BranchedKStream
-
Define a branch for records that match the predicate.
- Branched<K,
V> - Class in org.apache.kafka.streams.kstream -
The
Branched
class is used to define the optional parameters when building branches withBranchedKStream
. - BranchedKStream<K,
V> - Interface in org.apache.kafka.streams.kstream -
Branches the records in the original stream based on the predicates supplied for the branch definitions.
- BrokerNotFoundException - Exception Class in org.apache.kafka.streams.errors
-
Indicates that none of the specified
brokers
could be found. - BrokerNotFoundException(String) - Constructor for exception class org.apache.kafka.streams.errors.BrokerNotFoundException
- BrokerNotFoundException(String, Throwable) - Constructor for exception class org.apache.kafka.streams.errors.BrokerNotFoundException
- BrokerNotFoundException(Throwable) - Constructor for exception class org.apache.kafka.streams.errors.BrokerNotFoundException
- BUFFERED_RECORDS_PER_PARTITION_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
buffered.records.per.partition
- BUFFERED_RECORDS_PER_PARTITION_DOC - Static variable in class org.apache.kafka.streams.StreamsConfig
-
Deprecated.
- build() - Method in interface org.apache.kafka.streams.state.StoreBuilder
-
Build the store as defined by the builder.
- build() - Method in class org.apache.kafka.streams.StreamsBuilder
-
Returns the
Topology
that represents the specified processing logic. - build(Properties) - Method in class org.apache.kafka.streams.StreamsBuilder
-
Returns the
Topology
that represents the specified processing logic and accepts aProperties
instance used to indicate whether to optimize topology or not. - buildFromEndpoint(String) - Static method in class org.apache.kafka.streams.state.HostInfo
- BUILT_IN_METRICS_VERSION_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
built.in.metrics.version
- BuiltInDslStoreSuppliers - Class in org.apache.kafka.streams.state
-
Collection of builtin
DslStoreSuppliers
for Kafka Streams. - BuiltInDslStoreSuppliers() - Constructor for class org.apache.kafka.streams.state.BuiltInDslStoreSuppliers
- BuiltInDslStoreSuppliers.InMemoryDslStoreSuppliers - Class in org.apache.kafka.streams.state
-
A
DslStoreSuppliers
that supplies all stores backed by an in-memory map - BuiltInDslStoreSuppliers.RocksDBDslStoreSuppliers - Class in org.apache.kafka.streams.state
-
A
DslStoreSuppliers
that supplies all stores backed by RocksDB - byDuration(Duration) - Static method in class org.apache.kafka.streams.AutoOffsetReset
-
Creates an
AutoOffsetReset
instance for the specified reset duration.
C
- CACHE_MAX_BYTES_BUFFERING_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
Deprecated.Since 3.4. Use
"statestore.cache.max.bytes"
instead. - CACHE_MAX_BYTES_BUFFERING_DOC - Static variable in class org.apache.kafka.streams.StreamsConfig
-
Deprecated.
- cacheSize - Variable in class org.apache.kafka.streams.TopologyConfig
- 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
-
Cancellable interface returned in
ProcessingContext.schedule(Duration, PunctuationType, Punctuator)
. - canMoveStandbyTask(KafkaStreamsState, KafkaStreamsState, TaskId, Map<ProcessId, KafkaStreamsAssignment>) - Method in interface org.apache.kafka.streams.processor.assignment.TaskAssignmentUtils.MoveStandbyTaskPredicate
- 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.
- cleanUp() - Method in class org.apache.kafka.streams.KafkaStreams
-
Do a cleanup of the local
StateStore
directory (StreamsConfig.STATE_DIR_CONFIG
) by deleting all data with regard to theapplication ID
. - CLIENT_ID_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
client.id
- CLIENT_TAG_PREFIX - Static variable in class org.apache.kafka.streams.StreamsConfig
-
Prefix used to add arbitrary tags to a Kafka Stream's instance as key-value pairs.
- clientInstanceIds(Duration) - Method in class org.apache.kafka.streams.KafkaStreams
-
Returns the internal clients' assigned
client instance ids
. - ClientInstanceIds - Interface in org.apache.kafka.streams
-
Encapsulates the
client instance id
used for metrics collection by producers, consumers, and the admin client used by Kafka Streams. - clientTagPrefix(String) - Static method in class org.apache.kafka.streams.StreamsConfig
-
Prefix a client tag key with
StreamsConfig.CLIENT_TAG_PREFIX
. - clientTags() - Method in interface org.apache.kafka.streams.processor.assignment.KafkaStreamsState
-
The client tags for this KafkaStreams client, if set any have been via configs using the
StreamsConfig.clientTagPrefix(java.lang.String)
- 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() - 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
-
Deprecated.Close this transformer and clean up any resources.
- close() - Method in interface org.apache.kafka.streams.kstream.ValueTransformer
-
Deprecated.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 interface org.apache.kafka.streams.processor.api.FixedKeyProcessor
-
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.StateStore
-
Close the storage engine.
- close() - Method in interface org.apache.kafka.streams.state.KeyValueIterator
- close() - Method in interface org.apache.kafka.streams.state.VersionedRecordIterator
- close() - Method in interface org.apache.kafka.streams.state.WindowStoreIterator
- close(String, Options) - Method in interface org.apache.kafka.streams.state.RocksDBConfigSetter
-
Close any user-constructed objects that inherit from
org.rocksdb.RocksObject
. - 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(KafkaStreams.CloseOptions) - 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. - CloseOptions() - Constructor for class org.apache.kafka.streams.KafkaStreams.CloseOptions
- cogroup(Aggregator<? super K, ? super V, VOut>) - Method in interface org.apache.kafka.streams.kstream.KGroupedStream
-
Create a new
CogroupedKStream
from this grouped KStream to allow cogrouping otherKGroupedStream
to it. - cogroup(KGroupedStream<K, V>, Aggregator<? super K, ? super V, VAgg>) - Method in interface org.apache.kafka.streams.kstream.CogroupedKStream
-
Add an already
grouped KStream
to thisCogroupedKStream
. - CogroupedKStream<K,
VAgg> - Interface in org.apache.kafka.streams.kstream -
CogroupedKStream
is an abstraction of multiple grouped record streams ofKeyValue
pairs. - Collecting branches in a single scope - Search tag in interface org.apache.kafka.streams.kstream.BranchedKStream
- Section
- commit() - Method in interface org.apache.kafka.streams.processor.api.ProcessingContext
-
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
- CommitCallback - Interface in org.apache.kafka.streams.processor
-
Stores can register this callback to be notified upon successful commit.
- committedOffsets() - Method in interface org.apache.kafka.streams.TaskMetadata
-
Offsets of the source topic partitions committed so far by the task.
- compareTo(ProcessId) - Method in class org.apache.kafka.streams.processor.assignment.ProcessId
- 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.LogAndContinueProcessingExceptionHandler
- configure(Map<String, ?>) - Method in class org.apache.kafka.streams.errors.LogAndFailExceptionHandler
- configure(Map<String, ?>) - Method in class org.apache.kafka.streams.errors.LogAndFailProcessingExceptionHandler
- configure(Map<String, ?>) - Method in enum class org.apache.kafka.streams.kstream.Materialized.StoreType
- configure(Map<String, ?>) - Method in interface org.apache.kafka.streams.processor.api.ProcessorWrapper
- configure(Map<String, ?>) - Method in interface org.apache.kafka.streams.processor.assignment.TaskAssignor
- configure(Map<String, ?>) - Method in interface org.apache.kafka.streams.state.DslStoreSuppliers
- 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
-
Connect a
processor
to one or morestate stores
. - Consumed<K,
V> - Class in org.apache.kafka.streams.kstream -
The
Consumed
class is used to define the optional parameters when usingStreamsBuilder
to build instances ofKStream
,KTable
, andGlobalKTable
. - CONSUMER_PREFIX - Static variable in class org.apache.kafka.streams.StreamsConfig
-
Prefix used to isolate
consumer
configs from other client configs. - consumerClientId() - Method in interface org.apache.kafka.streams.ThreadMetadata
-
Client ID of the Kafka consumer used by the stream thread.
- consumerClientIds() - Method in interface org.apache.kafka.streams.processor.assignment.KafkaStreamsState
- consumerInstanceIds() - Method in interface org.apache.kafka.streams.ClientInstanceIds
-
Returns the
client instance id
of the consumers. - consumerPrefix(String) - Static method in class org.apache.kafka.streams.StreamsConfig
-
Prefix a property with
StreamsConfig.CONSUMER_PREFIX
. - ContextualFixedKeyProcessor<KIn,
VIn, - Class in org.apache.kafka.streams.processor.apiVOut> -
An abstract implementation of
FixedKeyProcessor
that manages theFixedKeyProcessorContext
instance. - ContextualProcessor<KIn,
VIn, - Class in org.apache.kafka.streams.processor.apiKOut, VOut> -
An abstract implementation of
Processor
that manages theProcessorContext
instance. - CONTINUE - Enum constant in enum class org.apache.kafka.streams.errors.DeserializationExceptionHandler.DeserializationHandlerResponse
-
Continue processing.
- CONTINUE - Enum constant in enum class org.apache.kafka.streams.errors.ProcessingExceptionHandler.ProcessingHandlerResponse
-
Continue processing.
- CONTINUE - Enum constant in enum class org.apache.kafka.streams.errors.ProductionExceptionHandler.ProductionExceptionHandlerResponse
-
Continue processing.
- convertToTimestampedFormat(byte[]) - Static method in interface org.apache.kafka.streams.state.TimestampedBytesStore
- copy() - Method in class org.apache.kafka.streams.query.Position
-
Create a deep copy of the Position.
- corruptedTasks() - Method in exception class 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() - Method in interface org.apache.kafka.streams.kstream.KGroupedTable
- 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() - 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, 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(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(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) - 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.KGroupedTable
- 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(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(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(Named, Materialized<K, Long, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KGroupedTable
- 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(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(Record<KIn, VIn>) - Static method in class org.apache.kafka.streams.processor.api.InternalFixedKeyRecordFactory
-
Only allowed way to create
FixedKeyRecord
s. - 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 underlyingStateStore
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
- CREATED - Enum constant in enum class org.apache.kafka.streams.KafkaStreams.State
- 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.api.ProcessingContext
-
Return the current stream-time in milliseconds.
- 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.api.ProcessingContext
-
Return the current system timestamp (also called wall-clock 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.
D
- DEFAULT_CLIENT_SUPPLIER_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
default.client.supplier
- DEFAULT_CLIENT_SUPPLIER_DOC - Static variable in class org.apache.kafka.streams.StreamsConfig
-
Deprecated.
- DEFAULT_DESERIALIZATION_EXCEPTION_HANDLER_CLASS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
Deprecated.Since 4.0. Use
StreamsConfig.DESERIALIZATION_EXCEPTION_HANDLER_CLASS_CONFIG
instead. - DEFAULT_DESERIALIZATION_EXCEPTION_HANDLER_CLASS_DOC - Static variable in class org.apache.kafka.streams.StreamsConfig
-
Deprecated.
- DEFAULT_DSL_STORE - Static variable in class org.apache.kafka.streams.StreamsConfig
-
Deprecated.
- DEFAULT_DSL_STORE_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
Deprecated.Since 3.7. Use
StreamsConfig.DSL_STORE_SUPPLIERS_CLASS_CONFIG
instead. - DEFAULT_DSL_STORE_DOC - Static variable in class org.apache.kafka.streams.StreamsConfig
-
Deprecated.
- DEFAULT_KEY_SERDE_CLASS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
default key.serde
- DEFAULT_PRODUCTION_EXCEPTION_HANDLER_CLASS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
Deprecated.Since 4.0. Use
StreamsConfig.PRODUCTION_EXCEPTION_HANDLER_CLASS_CONFIG
instead. - DEFAULT_STICKY_NON_OVERLAP_COST - Static variable in class org.apache.kafka.streams.processor.assignment.assignors.StickyTaskAssignor
- DEFAULT_STICKY_TRAFFIC_COST - Static variable in class org.apache.kafka.streams.processor.assignment.assignors.StickyTaskAssignor
- DEFAULT_TIMESTAMP_EXTRACTOR_CLASS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
default.timestamp.extractor
- DEFAULT_TIMESTAMP_EXTRACTOR_CLASS_DOC - Static variable in class org.apache.kafka.streams.StreamsConfig
-
Deprecated.
- DEFAULT_VALUE_SERDE_CLASS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
default.value.serde
- defaultBranch() - Method in interface org.apache.kafka.streams.kstream.BranchedKStream
-
Finalize the construction of branches and defines the default branch for the messages not intercepted by other branches.
- defaultBranch(Branched<K, V>) - Method in interface org.apache.kafka.streams.kstream.BranchedKStream
-
Finalize the construction of branches and defines the default branch for the messages not intercepted by other branches.
- defaultDeserializationExceptionHandler() - Method in class org.apache.kafka.streams.StreamsConfig
-
Deprecated.Since 4.0. Use
StreamsConfig.deserializationExceptionHandler()
instead. - defaultKeySerde() - Method in class org.apache.kafka.streams.StreamsConfig
-
Return an
configured
instance ofkey Serde class
. - defaultProductionExceptionHandler() - Method in class org.apache.kafka.streams.StreamsConfig
-
Deprecated.Since 4.0. Use
StreamsConfig.productionExceptionHandler()
instead. - DefaultProductionExceptionHandler - Class in org.apache.kafka.streams.errors
-
ProductionExceptionHandler
that always instructs streams to fail when an exception happens while attempting to produce result records. - DefaultProductionExceptionHandler() - Constructor for class org.apache.kafka.streams.errors.DefaultProductionExceptionHandler
- defaultStandbyTaskAssignment(ApplicationState, Map<ProcessId, KafkaStreamsAssignment>) - Static method in class org.apache.kafka.streams.processor.assignment.TaskAssignmentUtils
-
Assign standby tasks to KafkaStreams clients according to the default logic.
- defaultTimestampExtractor() - Method in class org.apache.kafka.streams.StreamsConfig
- defaultValueSerde() - Method in class org.apache.kafka.streams.StreamsConfig
-
Return an
configured
instance ofvalue Serde class
. - delete(K) - Method in interface org.apache.kafka.streams.state.KeyValueStore
-
Delete the value from the store (if there is one).
- delete(K, long) - Method in interface org.apache.kafka.streams.state.VersionedKeyValueStore
-
Delete the value associated with this key from the store, at the specified timestamp (if there is such a value), and return the deleted value.
- delete(Bytes, long) - Method in interface org.apache.kafka.streams.state.VersionedBytesStore
-
The analog of
VersionedKeyValueStore.delete(Object, long)
. - DESCENDING - Enum constant in enum class org.apache.kafka.streams.query.ResultOrder
- describe() - Method in class org.apache.kafka.streams.Topology
-
Returns a description of the specified
Topology
. - DESERIALIZATION_EXCEPTION_HANDLER_CLASS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
deserialization.exception.handler
- deserializationExceptionHandler - Variable in class org.apache.kafka.streams.TopologyConfig.TaskConfig
- deserializationExceptionHandler() - Method in class org.apache.kafka.streams.StreamsConfig
- DeserializationExceptionHandler - Interface in org.apache.kafka.streams.errors
-
Interface that specifies how an exception from source node deserialization (e.g., reading from Kafka) should be handled.
- DeserializationExceptionHandler.DeserializationHandlerResponse - Enum Class in org.apache.kafka.streams.errors
-
Enumeration that describes the response from the exception handler.
- deserializationExceptionHandlerSupplier - Variable in class org.apache.kafka.streams.TopologyConfig
- deserialize(String, byte[]) - Method in class org.apache.kafka.streams.kstream.SessionWindowedDeserializer
- deserialize(String, byte[]) - Method in class org.apache.kafka.streams.kstream.TimeWindowedDeserializer
- Direct Branch Consuming - Search tag in interface org.apache.kafka.streams.kstream.BranchedKStream
- Section
- DOES_NOT_EXIST - Enum constant in enum class org.apache.kafka.streams.query.FailureReason
-
The requested store partition does not exist at all.
- DSL_STORE_SUPPLIERS_CLASS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
dsl.store.suppliers.class
- DslKeyValueParams - Class in org.apache.kafka.streams.state
-
DslKeyValueParams
is a wrapper class for all parameters that function as inputs toDslStoreSuppliers.keyValueStore(DslKeyValueParams)
. - DslKeyValueParams(String, boolean) - Constructor for class org.apache.kafka.streams.state.DslKeyValueParams
- DslSessionParams - Class in org.apache.kafka.streams.state
-
DslSessionParams
is a wrapper class for all parameters that function as inputs toDslStoreSuppliers.sessionStore(DslSessionParams)
. - DslSessionParams(String, Duration, EmitStrategy) - Constructor for class org.apache.kafka.streams.state.DslSessionParams
- dslStoreSuppliers - Variable in class org.apache.kafka.streams.TopologyConfig
- DslStoreSuppliers - Interface in org.apache.kafka.streams.state
-
DslStoreSuppliers
defines a grouping of factories to construct stores for each of the types of state store implementations in Kafka Streams. - DslWindowParams - Class in org.apache.kafka.streams.state
-
DslWindowParams
is a wrapper class for all parameters that function as inputs toDslStoreSuppliers.windowStore(DslWindowParams)
. - DslWindowParams(String, Duration, Duration, boolean, EmitStrategy, boolean, boolean) - Constructor for class org.apache.kafka.streams.state.DslWindowParams
- DUMMY_THREAD_INDEX - Static variable in class org.apache.kafka.streams.StreamsConfig
-
Deprecated.
- Dynamic branching - Search tag in interface org.apache.kafka.streams.kstream.BranchedKStream
- Section
E
- earliest() - Static method in class org.apache.kafka.streams.AutoOffsetReset
-
Creates an
AutoOffsetReset
instance representing "earliest". - EARLIEST - Enum constant in enum class org.apache.kafka.streams.Topology.AutoOffsetReset
-
Deprecated.
- EMIT_INTERVAL_MS_KSTREAMS_OUTER_JOIN_SPURIOUS_RESULTS_FIX - Static variable in class org.apache.kafka.streams.StreamsConfig.InternalConfig
- EMIT_INTERVAL_MS_KSTREAMS_WINDOWED_AGGREGATION - Static variable in class org.apache.kafka.streams.StreamsConfig.InternalConfig
- emitEarlyWhenFull() - Method in interface org.apache.kafka.streams.kstream.Suppressed.BufferConfig
-
Set the buffer to just emit the oldest records when any of its constraints are violated.
- emitStrategy() - Method in class org.apache.kafka.streams.state.DslSessionParams
- emitStrategy() - Method in class org.apache.kafka.streams.state.DslWindowParams
- emitStrategy(EmitStrategy) - Method in interface org.apache.kafka.streams.kstream.SessionWindowedKStream
-
Configure when the aggregated result will be emitted for
SessionWindowedKStream
. - emitStrategy(EmitStrategy) - Method in interface org.apache.kafka.streams.kstream.TimeWindowedKStream
-
Configure when the aggregated result will be emitted for
TimeWindowedKStream
. - EmitStrategy - Interface in org.apache.kafka.streams.kstream
-
This interface controls the strategy that can be used to control how we emit results in a processor.
- EmitStrategy.StrategyType - Enum Class in org.apache.kafka.streams.kstream
- emptyPosition() - Static method in class org.apache.kafka.streams.query.Position
-
Create a new, empty Position.
- ENABLE_METRICS_PUSH_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
enable.metrics.push
- ENABLE_METRICS_PUSH_DOC - Static variable in class org.apache.kafka.streams.StreamsConfig
-
Deprecated.
- enableExecutionInfo() - Method in class org.apache.kafka.streams.query.StateQueryRequest
-
Requests for stores and the Streams runtime to record any useful details about how the query was executed.
- enableStaleStores() - Method in class org.apache.kafka.streams.StoreQueryParameters
-
Enable querying of stale state stores, i.e., allow to query active tasks during restore as well as standby tasks.
- end() - Method in class org.apache.kafka.streams.kstream.Window
-
Return the end timestamp of this window.
- endOffsetPosition() - Method in class org.apache.kafka.streams.LagInfo
-
Get the end offset position for this store partition's changelog topic on the Kafka brokers.
- endOffsets() - Method in interface org.apache.kafka.streams.TaskMetadata
-
End offsets of the source topic partitions of the task.
- endTime() - Method in class org.apache.kafka.streams.kstream.Window
-
Return the end time of this window.
- eosEnabled - Variable in class org.apache.kafka.streams.TopologyConfig
- eosEnabled - Variable in class org.apache.kafka.streams.TopologyConfig.TaskConfig
- equals(Object) - Method in class org.apache.kafka.streams.AutoOffsetReset
- equals(Object) - Method in class org.apache.kafka.streams.KeyQueryMetadata
- equals(Object) - Method in class org.apache.kafka.streams.KeyValue
- equals(Object) - Method in class org.apache.kafka.streams.kstream.Consumed
- equals(Object) - Method in class org.apache.kafka.streams.kstream.JoinWindows
- equals(Object) - Method in class org.apache.kafka.streams.kstream.Produced
- equals(Object) - Method in class org.apache.kafka.streams.kstream.SessionWindows
- equals(Object) - Method in class org.apache.kafka.streams.kstream.SlidingWindows
- equals(Object) - Method in class org.apache.kafka.streams.kstream.TimeWindows
- equals(Object) - Method in class org.apache.kafka.streams.kstream.UnlimitedWindows
- equals(Object) - Method in class org.apache.kafka.streams.kstream.Window
- equals(Object) - Method in class org.apache.kafka.streams.kstream.Windowed
- equals(Object) - Method in class org.apache.kafka.streams.LagInfo
- equals(Object) - Method in class org.apache.kafka.streams.processor.api.FixedKeyRecord
- equals(Object) - Method in class org.apache.kafka.streams.processor.api.Record
- equals(Object) - Method in class org.apache.kafka.streams.processor.assignment.KafkaStreamsAssignment.AssignedTask
- equals(Object) - Method in class org.apache.kafka.streams.processor.assignment.ProcessId
- equals(Object) - Method in class org.apache.kafka.streams.processor.TaskId
- equals(Object) - Method in class org.apache.kafka.streams.processor.To
- equals(Object) - Method in class org.apache.kafka.streams.query.Position
- equals(Object) - Method in class org.apache.kafka.streams.query.PositionBound
- equals(Object) - Method in class org.apache.kafka.streams.state.DslKeyValueParams
- equals(Object) - Method in class org.apache.kafka.streams.state.DslSessionParams
- equals(Object) - Method in class org.apache.kafka.streams.state.DslWindowParams
- equals(Object) - Method in class org.apache.kafka.streams.state.HostInfo
- equals(Object) - Method in class org.apache.kafka.streams.state.ValueAndTimestamp
- equals(Object) - Method in class org.apache.kafka.streams.state.VersionedRecord
- equals(Object) - Method in class org.apache.kafka.streams.StoreQueryParameters
- equals(Object) - Method in interface org.apache.kafka.streams.StreamsMetadata
-
Compares the specified object with this StreamsMetadata.
- equals(Object) - Method in interface org.apache.kafka.streams.TaskMetadata
-
Compares the specified object with this TaskMetadata.
- equals(Object) - Method in interface org.apache.kafka.streams.ThreadMetadata
-
Compares the specified object with this ThreadMetadata.
- ERROR - Enum constant in enum class org.apache.kafka.streams.KafkaStreams.State
- ErrorHandlerContext - Interface in org.apache.kafka.streams.errors
-
This interface allows user code to inspect the context of a record that has failed during processing.
- EXACTLY_ONCE_V2 - Static variable in class org.apache.kafka.streams.StreamsConfig
-
Config value for parameter
"processing.guarantee"
for exactly-once processing guarantees. - executionInfoEnabled() - Method in class org.apache.kafka.streams.query.StateQueryRequest
-
Whether the request includes detailed execution information.
- extract(K, V, RecordContext) - Method in interface org.apache.kafka.streams.processor.TopicNameExtractor
-
Extracts the topic name to send to.
- extract(ConsumerRecord<Object, Object>, long) - Method in class org.apache.kafka.streams.processor.FailOnInvalidTimestamp
-
Extracts the embedded metadata timestamp from the given
ConsumerRecord
. - extract(ConsumerRecord<Object, Object>, long) - Method in class org.apache.kafka.streams.processor.LogAndSkipOnInvalidTimestamp
-
Extracts the embedded metadata timestamp from the given
ConsumerRecord
. - extract(ConsumerRecord<Object, Object>, long) - Method in class org.apache.kafka.streams.processor.UsePartitionTimeOnInvalidTimestamp
-
Extracts the embedded metadata timestamp from the given
ConsumerRecord
. - extract(ConsumerRecord<Object, Object>, long) - Method in interface org.apache.kafka.streams.processor.TimestampExtractor
-
Extracts a timestamp from a record.
- extract(ConsumerRecord<Object, Object>, long) - Method in class org.apache.kafka.streams.processor.WallclockTimestampExtractor
-
Return the current wall clock time as timestamp.
F
- FAIL - Enum constant in enum class org.apache.kafka.streams.errors.DeserializationExceptionHandler.DeserializationHandlerResponse
-
Fail processing.
- FAIL - Enum constant in enum class org.apache.kafka.streams.errors.ProcessingExceptionHandler.ProcessingHandlerResponse
-
Fail processing.
- FAIL - Enum constant in enum class org.apache.kafka.streams.errors.ProductionExceptionHandler.ProductionExceptionHandlerResponse
-
Fail processing.
- 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
- FailureReason - Enum Class in org.apache.kafka.streams.query
-
This enumeration type captures the various top-level reasons that a particular partition of a store would fail to execute a query.
- fetch(K) - Method in interface org.apache.kafka.streams.state.ReadOnlySessionStore
-
Retrieve all aggregated sessions for the provided key.
- fetch(K, long) - Method in interface org.apache.kafka.streams.state.ReadOnlyWindowStore
-
Get the value of key from a window.
- 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.ReadOnlyWindowStore
-
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) - Method in interface org.apache.kafka.streams.state.ReadOnlySessionStore
-
Retrieve all aggregated sessions for the given range of keys.
- 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.ReadOnlyWindowStore
-
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(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.ReadOnlyWindowStore
-
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>) - Method in interface org.apache.kafka.streams.kstream.KTable
-
Create a new
KTable
that consists of all records of thisKTable
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 thisKTable
which satisfy the given predicate, with thekey serde
,value serde
, and the underlyingmaterialized state storage
configured in theMaterialized
instance. - 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>, Named) - Method in interface org.apache.kafka.streams.kstream.KTable
-
Create a new
KTable
that consists of all records of thisKTable
which satisfy the given predicate, with default serializers, deserializers, and state store. - 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 thisKTable
which satisfy the given predicate, with thekey serde
,value serde
, and the underlyingmaterialized state storage
configured in theMaterialized
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>) - Method in interface org.apache.kafka.streams.kstream.KTable
-
Create a new
KTable
that consists all records of thisKTable
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 thisKTable
which do not satisfy the given predicate, with thekey serde
,value serde
, and the underlyingmaterialized state storage
configured in theMaterialized
instance. - 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>, Named) - Method in interface org.apache.kafka.streams.kstream.KTable
-
Create a new
KTable
that consists all records of thisKTable
which do not satisfy the given predicate, with default serializers, deserializers, and state store. - 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 thisKTable
which do not satisfy the given predicate, with thekey serde
,value serde
, and the underlyingmaterialized state storage
configured in theMaterialized
instance. - findSessions(long, long) - Method in interface org.apache.kafka.streams.state.SessionStore
-
Return all the session window entries that ends between the specified range (both ends are inclusive).
- 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, Instant, Instant) - Method in interface org.apache.kafka.streams.state.SessionStore
- 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, K, Instant, Instant) - Method in interface org.apache.kafka.streams.state.SessionStore
- FixedKeyProcessor<KIn,
VIn, - Interface in org.apache.kafka.streams.processor.apiVOut> -
A processor of key-value pair records where keys are immutable.
- FixedKeyProcessorContext<KForward,
VForward> - Interface in org.apache.kafka.streams.processor.api -
Processor context interface for
FixedKeyRecord
. - FixedKeyProcessorSupplier<KIn,
VIn, - Interface in org.apache.kafka.streams.processor.apiVOut> -
A processor supplier that can create one or more
FixedKeyProcessor
instances. - FixedKeyRecord<K,
V> - Class in org.apache.kafka.streams.processor.api -
A data class representing an incoming record with fixed key for processing in a
FixedKeyProcessor
or a record to forward to downstream processors viaFixedKeyProcessorContext
. - 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. - flush() - Method in interface org.apache.kafka.streams.processor.StateStore
-
Flush any cached data
- followupRebalanceDeadline() - Method in class org.apache.kafka.streams.processor.assignment.KafkaStreamsAssignment
- 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 akey-value pair
. - ForeachProcessor<K,
V> - Class in org.apache.kafka.streams.kstream -
Deprecated.Since 4.0 and should not be used any longer.
- ForeachProcessor(ForeachAction<K, V>) - Constructor for class org.apache.kafka.streams.kstream.ForeachProcessor
-
Deprecated.
- forFailure(FailureReason, String) - Static method in interface org.apache.kafka.streams.query.QueryResult
-
Static factory method to create a result object for a failed query.
- forResult(R) - Static method in interface org.apache.kafka.streams.query.QueryResult
-
Static factory method to create a result object for a successful query.
- forStatefulTasks() - Method in class org.apache.kafka.streams.processor.assignment.TaskAssignmentUtils.RackAwareOptimizationParams
-
Return a new config object with the tasksToOptimize set to all stateful tasks in the given ApplicationState
- forStatelessTasks() - Method in class org.apache.kafka.streams.processor.assignment.TaskAssignmentUtils.RackAwareOptimizationParams
-
Return a new config object with the tasksToOptimize set to all stateless tasks in the given ApplicationState
- forTasks(SortedSet<TaskId>) - Method in class org.apache.kafka.streams.processor.assignment.TaskAssignmentUtils.RackAwareOptimizationParams
-
Return a new config object with the provided tasksToOptimize
- forType(EmitStrategy.StrategyType) - Static method in enum class org.apache.kafka.streams.kstream.EmitStrategy.StrategyType
- forUnknownQueryType(Query<R>, StateStore) - Static method in interface org.apache.kafka.streams.query.QueryResult
-
Static factory method to create a failed query result object to indicate that the store does not know how to handle the query.
- 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.
- forward(FixedKeyRecord<K, V>) - Method in interface org.apache.kafka.streams.processor.api.FixedKeyProcessorContext
-
Forward a record to all child processors.
- forward(FixedKeyRecord<K, V>, String) - Method in interface org.apache.kafka.streams.processor.api.FixedKeyProcessorContext
-
Forward a record to the specified child processor.
- 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.
- fromMap(Map<String, ? extends Map<Integer, Long>>) - Static method in class org.apache.kafka.streams.query.Position
-
Create a new Position and populate it with a mapping of topic -> partition -> offset.
- fromNameAndType(String, QueryableStoreType<T>) - Static method in class org.apache.kafka.streams.StoreQueryParameters
- fromTime() - Method in class org.apache.kafka.streams.query.MultiVersionedKeyQuery
-
The starting time point of the query, if specified
- fromTime(Instant) - Method in class org.apache.kafka.streams.query.MultiVersionedKeyQuery
-
Specifies the starting time point for the key query.
G
- get() - Method in interface org.apache.kafka.streams.kstream.TransformerSupplier
-
Deprecated.Return a newly constructed
Transformer
instance. - get() - Method in interface org.apache.kafka.streams.kstream.ValueTransformerSupplier
-
Deprecated.Return a newly constructed
ValueTransformer
instance. - get() - Method in interface org.apache.kafka.streams.kstream.ValueTransformerWithKeySupplier
-
Return a newly constructed
ValueTransformerWithKey
instance. - get() - Method in interface org.apache.kafka.streams.processor.api.FixedKeyProcessorSupplier
-
Return a newly constructed
FixedKeyProcessor
instance. - get() - Method in interface org.apache.kafka.streams.processor.api.ProcessorSupplier
-
Return a newly constructed
Processor
instance. - get() - Method in interface org.apache.kafka.streams.state.StoreSupplier
-
Return a new
StateStore
instance. - get(K) - Method in interface org.apache.kafka.streams.state.ReadOnlyKeyValueStore
-
Get the value corresponding to this key.
- get(K) - Method in interface org.apache.kafka.streams.state.VersionedKeyValueStore
-
Get the current (i.e., latest by timestamp) record associated with this key.
- get(K, long) - Method in interface org.apache.kafka.streams.state.VersionedKeyValueStore
-
Get the record associated with this key as of the specified timestamp (i.e., the existing record with the largest timestamp not exceeding the provided timestamp bound).
- get(Bytes, long) - Method in interface org.apache.kafka.streams.state.VersionedBytesStore
-
The analog of
VersionedKeyValueStore.get(Object, long)
. - getAdmin(Map<String, Object>) - Method in interface org.apache.kafka.streams.KafkaClientSupplier
-
Create an
Admin
which is used for internal topic management. - getAdminConfigs(String) - Method in class org.apache.kafka.streams.StreamsConfig
-
Get the configs for the
admin client
. - getBoolean(Map<String, Object>, String, boolean) - Static method in class org.apache.kafka.streams.StreamsConfig.InternalConfig
- getClientTags() - Method in class org.apache.kafka.streams.StreamsConfig
-
Get the configured client tags set with
StreamsConfig.CLIENT_TAG_PREFIX
prefix. - getConsumer(Map<String, Object>) - Method in interface org.apache.kafka.streams.KafkaClientSupplier
-
Create a
Consumer
which is used to read records of source topics. - getExecutionInfo() - Method in interface org.apache.kafka.streams.query.QueryResult
-
If detailed execution information was requested in
StateQueryRequest.enableExecutionInfo()
, this method returned the execution details for this partition's result. - getFailureMessage() - Method in interface org.apache.kafka.streams.query.QueryResult
-
If this partition failed to execute the query, returns the failure message.
- getFailureReason() - Method in interface org.apache.kafka.streams.query.QueryResult
-
If this partition failed to execute the query, returns the reason.
- getGlobalConsumer(Map<String, Object>) - Method in interface org.apache.kafka.streams.KafkaClientSupplier
-
Create a
Consumer
which is used to consume records forGlobalKTable
. - getGlobalConsumerConfigs(String) - Method in class org.apache.kafka.streams.StreamsConfig
-
Get the configs for the
global consumer
. - getGlobalResult() - Method in class org.apache.kafka.streams.query.StateQueryResult
-
The query's result for global store queries.
- getKafkaClientSupplier() - Method in class org.apache.kafka.streams.StreamsConfig
-
Return configured KafkaClientSupplier
- getKey() - Method in class org.apache.kafka.streams.query.KeyQuery
-
Return the key that was specified for this query.
- getKey() - Method in class org.apache.kafka.streams.query.WindowKeyQuery
- getKey() - Method in class org.apache.kafka.streams.query.WindowRangeQuery
- getLong(Map<String, Object>, String, long) - Static method in class org.apache.kafka.streams.StreamsConfig.InternalConfig
- getLowerBound() - Method in class org.apache.kafka.streams.query.RangeQuery
-
The lower bound of the query, if specified.
- getMainConsumerConfigs(String, String, int) - Method in class org.apache.kafka.streams.StreamsConfig
-
Get the configs to the
main consumer
. - getOnlyPartitionResult() - Method in class org.apache.kafka.streams.query.StateQueryResult
-
For queries that are expected to match records in only one partition, returns the result.
- getPartitionPositions(String) - Method in class org.apache.kafka.streams.query.Position
-
Return the partition -> offset mapping for a specific topic.
- getPartitionResults() - Method in class org.apache.kafka.streams.query.StateQueryResult
-
The query's result for each partition that executed the query.
- getPartitions() - Method in class org.apache.kafka.streams.query.StateQueryRequest
-
If the request is for specific partitions, return the set of partitions to query.
- getPosition() - Method in interface org.apache.kafka.streams.processor.StateStore
-
Returns the position the state store is at with respect to the input topic/partitions
- getPosition() - Method in interface org.apache.kafka.streams.query.QueryResult
-
This state partition's exact position in its history when this query was executed.
- getPosition() - Method in class org.apache.kafka.streams.query.StateQueryResult
-
The position of the state store at the moment it executed the query.
- getPositionBound() - Method in class org.apache.kafka.streams.query.StateQueryRequest
-
The bound that this request places on its query, in terms of the partitions' positions against its inputs.
- getProducer(Map<String, Object>) - Method in interface org.apache.kafka.streams.KafkaClientSupplier
-
Create a
Producer
which is used to write records to sink topics. - getProducerConfigs(String) - Method in class org.apache.kafka.streams.StreamsConfig
-
Get the configs for the
producer
. - getQuery() - Method in class org.apache.kafka.streams.query.StateQueryRequest
-
The query this request is meant to run.
- getRestoreConsumer(Map<String, Object>) - Method in interface org.apache.kafka.streams.KafkaClientSupplier
-
Create a
Consumer
which is used to read records to restoreStateStore
s. - getRestoreConsumerConfigs(String) - Method in class org.apache.kafka.streams.StreamsConfig
-
Get the configs for the
restore-consumer
. - getResult() - Method in interface org.apache.kafka.streams.query.QueryResult
-
Returns the result of executing the query on one partition.
- getStateStore(String) - Method in interface org.apache.kafka.streams.processor.api.ProcessingContext
-
Get the state store given the store name.
- getStateStore(String) - Method in interface org.apache.kafka.streams.processor.ProcessorContext
-
Get the state store given the store name.
- getStoreName() - Method in class org.apache.kafka.streams.query.StateQueryRequest
-
The name of the store this request is for.
- getString(Map<String, Object>, String, String) - Static method in class org.apache.kafka.streams.StreamsConfig.InternalConfig
- getTaskConfig() - Method in class org.apache.kafka.streams.TopologyConfig
- getTimeFrom() - Method in class org.apache.kafka.streams.query.WindowKeyQuery
- getTimeFrom() - Method in class org.apache.kafka.streams.query.WindowRangeQuery
- getTimeTo() - Method in class org.apache.kafka.streams.query.WindowKeyQuery
- getTimeTo() - Method in class org.apache.kafka.streams.query.WindowRangeQuery
- getTopics() - Method in class org.apache.kafka.streams.query.Position
-
Return the topics that are represented in this Position.
- getUpperBound() - Method in class org.apache.kafka.streams.query.RangeQuery
-
The upper bound of the query, if specified
- getValueOrNull(ValueAndTimestamp<V>) - Static method in class org.apache.kafka.streams.state.ValueAndTimestamp
-
Return the wrapped
value
of the givenvalueAndTimestamp
parameter if the parameter is notnull
. - getWindowSize() - Method in class org.apache.kafka.streams.kstream.TimeWindowedDeserializer
- GLOBAL_CONSUMER_PREFIX - Static variable in class org.apache.kafka.streams.StreamsConfig
-
Prefix used to override
consumer
configs for the global consumer client from the general consumer client configs. - globalConsumerPrefix(String) - Static method in class org.apache.kafka.streams.StreamsConfig
-
Prefix a property with
StreamsConfig.GLOBAL_CONSUMER_PREFIX
. - GlobalKTable<K,
V> - Interface in org.apache.kafka.streams.kstream -
GlobalKTable
is an abstraction of a changelog stream from a primary-keyed table. - globalStores() - Method in interface org.apache.kafka.streams.TopologyDescription
-
All global stores of the represented topology.
- globalTable(String) - Method in class org.apache.kafka.streams.StreamsBuilder
-
Create a
GlobalKTable
for the specified topic. - globalTable(String, Consumed<K, V>) - Method in class org.apache.kafka.streams.StreamsBuilder
-
Create a
GlobalKTable
for the specified topic. - globalTable(String, Consumed<K, V>, Materialized<K, V, KeyValueStore<Bytes, byte[]>>) - Method in class org.apache.kafka.streams.StreamsBuilder
-
Create a
GlobalKTable
for the specified topic. - globalTable(String, Materialized<K, V, KeyValueStore<Bytes, byte[]>>) - Method in class org.apache.kafka.streams.StreamsBuilder
-
Create a
GlobalKTable
for the specified topic. - grace(Duration) - Method in class org.apache.kafka.streams.kstream.JoinWindows
-
Deprecated.Since 3.0. Use
JoinWindows.ofTimeDifferenceAndGrace(Duration, Duration)
instead. - gracePeriod() - Method in class org.apache.kafka.streams.kstream.Joined
-
Deprecated.Since 4.0 and should not be used any longer.
- gracePeriodMs() - Method in class org.apache.kafka.streams.kstream.JoinWindows
- gracePeriodMs() - Method in class org.apache.kafka.streams.kstream.SessionWindows
- gracePeriodMs() - Method in class org.apache.kafka.streams.kstream.SlidingWindows
- gracePeriodMs() - Method in class org.apache.kafka.streams.kstream.TimeWindows
- gracePeriodMs() - Method in class org.apache.kafka.streams.kstream.UnlimitedWindows
- gracePeriodMs() - Method in class org.apache.kafka.streams.kstream.Windows
-
Return the window grace period (the time to admit out-of-order events after the end of the window.) Delay is defined as (stream_time - record_timestamp).
- groupBy(KeyValueMapper<? super K, ? super V, KR>) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Group the records of this
KStream
on a new key that is selected using the providedKeyValueMapper
and default serializers and deserializers. - groupBy(KeyValueMapper<? super K, ? super V, KR>, Grouped<KR, V>) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Group the records of this
KStream
on a new key that is selected using the providedKeyValueMapper
andSerde
s as specified byGrouped
. - groupBy(KeyValueMapper<? super K, ? super V, KeyValue<KR, VR>>) - Method in interface org.apache.kafka.streams.kstream.KTable
-
Re-groups the records of this
KTable
using the providedKeyValueMapper
and default serializers and deserializers. - groupBy(KeyValueMapper<? super K, ? super V, KeyValue<KR, VR>>, Grouped<KR, VR>) - Method in interface org.apache.kafka.streams.kstream.KTable
-
Re-groups the records of this
KTable
using the providedKeyValueMapper
andSerde
s as specified byGrouped
. - groupByKey() - Method in interface org.apache.kafka.streams.kstream.KStream
-
Group the records by their current key into a
KGroupedStream
while preserving the original values and default serializers and deserializers. - groupByKey(Grouped<K, V>) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Group the records by their current key into a
KGroupedStream
while preserving the original values and using the serializers as defined byGrouped
. - Grouped<K,
V> - Class in org.apache.kafka.streams.kstream -
The class that is used to capture the key and value
Serde
s and set the part of name used for repartition topics when performingKStream.groupBy(KeyValueMapper, Grouped)
,KStream.groupByKey(Grouped)
, orKTable.groupBy(KeyValueMapper, Grouped)
operations.
H
- handle(Throwable) - Method in interface org.apache.kafka.streams.errors.StreamsUncaughtExceptionHandler
-
Inspect the exception received in a stream thread and respond with an action.
- handle(ProducerRecord<byte[], byte[]>, Exception) - Method in class org.apache.kafka.streams.errors.DefaultProductionExceptionHandler
-
Deprecated.Since 3.9. Use
DefaultProductionExceptionHandler.handle(ErrorHandlerContext, ProducerRecord, Exception)
instead. - handle(ProducerRecord<byte[], byte[]>, Exception) - Method in interface org.apache.kafka.streams.errors.ProductionExceptionHandler
-
Deprecated.Since 3.9. Use
ProductionExceptionHandler.handle(ErrorHandlerContext, ProducerRecord, Exception)
instead. - handle(ErrorHandlerContext, ConsumerRecord<byte[], byte[]>, Exception) - Method in interface org.apache.kafka.streams.errors.DeserializationExceptionHandler
-
Inspect a record and the exception received.
- handle(ErrorHandlerContext, ConsumerRecord<byte[], byte[]>, Exception) - Method in class org.apache.kafka.streams.errors.LogAndContinueExceptionHandler
- handle(ErrorHandlerContext, ConsumerRecord<byte[], byte[]>, Exception) - Method in class org.apache.kafka.streams.errors.LogAndFailExceptionHandler
- handle(ErrorHandlerContext, ProducerRecord<byte[], byte[]>, Exception) - Method in class org.apache.kafka.streams.errors.DefaultProductionExceptionHandler
- handle(ErrorHandlerContext, ProducerRecord<byte[], byte[]>, Exception) - Method in interface org.apache.kafka.streams.errors.ProductionExceptionHandler
-
Inspect a record that we attempted to produce, and the exception that resulted from attempting to produce it and determine to continue or stop processing.
- handle(ErrorHandlerContext, Record<?, ?>, Exception) - Method in class org.apache.kafka.streams.errors.LogAndContinueProcessingExceptionHandler
- handle(ErrorHandlerContext, Record<?, ?>, Exception) - Method in class org.apache.kafka.streams.errors.LogAndFailProcessingExceptionHandler
- handle(ErrorHandlerContext, Record<?, ?>, Exception) - Method in interface org.apache.kafka.streams.errors.ProcessingExceptionHandler
-
Inspect a record and the exception received
- handle(ProcessorContext, ConsumerRecord<byte[], byte[]>, Exception) - Method in interface org.apache.kafka.streams.errors.DeserializationExceptionHandler
-
Deprecated.Since 3.9. Use
DeserializationExceptionHandler.handle(ErrorHandlerContext, ConsumerRecord, Exception)
instead. - handle(ProcessorContext, ConsumerRecord<byte[], byte[]>, Exception) - Method in class org.apache.kafka.streams.errors.LogAndContinueExceptionHandler
-
Deprecated.Since 3.9. Use
LogAndContinueExceptionHandler.handle(ErrorHandlerContext, ConsumerRecord, Exception)
instead. - handle(ProcessorContext, ConsumerRecord<byte[], byte[]>, Exception) - Method in class org.apache.kafka.streams.errors.LogAndFailExceptionHandler
-
Deprecated.Since 3.9. Use
LogAndFailExceptionHandler.handle(ErrorHandlerContext, ConsumerRecord, Exception)
instead. - handleSerializationException(ProducerRecord, Exception) - Method in interface org.apache.kafka.streams.errors.ProductionExceptionHandler
-
Deprecated.
- handleSerializationException(ErrorHandlerContext, ProducerRecord, Exception, ProductionExceptionHandler.SerializationExceptionOrigin) - Method in interface org.apache.kafka.streams.errors.ProductionExceptionHandler
-
Handles serialization exception and determine if the process should continue.
- hasCompletedShutdown() - Method in enum class org.apache.kafka.streams.KafkaStreams.State
- hashCode() - Method in class org.apache.kafka.streams.AutoOffsetReset
- hashCode() - Method in class org.apache.kafka.streams.KeyQueryMetadata
- hashCode() - Method in class org.apache.kafka.streams.KeyValue
- hashCode() - Method in class org.apache.kafka.streams.kstream.Consumed
- hashCode() - Method in class org.apache.kafka.streams.kstream.JoinWindows
- hashCode() - Method in class org.apache.kafka.streams.kstream.Produced
- hashCode() - Method in class org.apache.kafka.streams.kstream.SessionWindows
- hashCode() - Method in class org.apache.kafka.streams.kstream.SlidingWindows
- hashCode() - Method in class org.apache.kafka.streams.kstream.TimeWindows
- hashCode() - Method in class org.apache.kafka.streams.kstream.UnlimitedWindows
- hashCode() - Method in class org.apache.kafka.streams.kstream.Window
- hashCode() - Method in class org.apache.kafka.streams.kstream.Windowed
- hashCode() - Method in class org.apache.kafka.streams.LagInfo
- hashCode() - Method in class org.apache.kafka.streams.processor.api.FixedKeyRecord
- hashCode() - Method in class org.apache.kafka.streams.processor.api.Record
- hashCode() - Method in class org.apache.kafka.streams.processor.assignment.KafkaStreamsAssignment.AssignedTask
- hashCode() - Method in class org.apache.kafka.streams.processor.assignment.ProcessId
- hashCode() - Method in class org.apache.kafka.streams.processor.TaskId
- hashCode() - Method in class org.apache.kafka.streams.processor.To
-
Equality is implemented in support of tests, *not* for use in Hash collections, since this class is mutable.
- hashCode() - Method in class org.apache.kafka.streams.query.Position
- hashCode() - Method in class org.apache.kafka.streams.query.PositionBound
- hashCode() - Method in class org.apache.kafka.streams.state.DslKeyValueParams
- hashCode() - Method in class org.apache.kafka.streams.state.DslSessionParams
- hashCode() - Method in class org.apache.kafka.streams.state.DslWindowParams
- hashCode() - Method in class org.apache.kafka.streams.state.HostInfo
- hashCode() - Method in class org.apache.kafka.streams.state.ValueAndTimestamp
- hashCode() - Method in class org.apache.kafka.streams.state.VersionedRecord
- hashCode() - Method in class org.apache.kafka.streams.StoreQueryParameters
- hashCode() - Method in interface org.apache.kafka.streams.StreamsMetadata
-
Returns the hash code value for this TaskMetadata.
- hashCode() - Method in interface org.apache.kafka.streams.TaskMetadata
-
Returns the hash code value for this TaskMetadata.
- hashCode() - Method in interface org.apache.kafka.streams.ThreadMetadata
-
Returns the hash code value for this ThreadMetadata.
- hasNotStarted() - Method in enum class org.apache.kafka.streams.KafkaStreams.State
- hasStartedOrFinishedShuttingDown() - Method in enum class org.apache.kafka.streams.KafkaStreams.State
- headers() - Method in interface org.apache.kafka.streams.errors.ErrorHandlerContext
-
Return the headers of the current source record; could be an empty header if it is not available.
- headers() - Method in class org.apache.kafka.streams.processor.api.FixedKeyRecord
-
The headers of the record.
- headers() - Method in class org.apache.kafka.streams.processor.api.Record
-
The headers of the record.
- headers() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
-
Return the headers of the current input record; could be an empty header if it is not available.
- headers() - Method in interface org.apache.kafka.streams.processor.RecordContext
-
Return the headers of the current input record; could be an empty header if it is not available.
- historyRetentionMs() - Method in interface org.apache.kafka.streams.state.VersionedBytesStoreSupplier
-
Returns the history retention (in milliseconds) that stores created from this supplier will have.
- host() - Method in class org.apache.kafka.streams.state.HostInfo
- host() - Method in interface org.apache.kafka.streams.StreamsMetadata
-
Host where the Streams client runs.
- hostInfo() - Method in interface org.apache.kafka.streams.processor.assignment.KafkaStreamsState
-
The
HostInfo
of this KafkaStreams client, if set via theapplication.server
config - hostInfo() - Method in interface org.apache.kafka.streams.StreamsMetadata
-
The value of
StreamsConfig.APPLICATION_SERVER_CONFIG
configured for the Streams client. - HostInfo - Class in org.apache.kafka.streams.state
-
Represents a user defined endpoint in a
KafkaStreams
application. - HostInfo(String, int) - Constructor for class org.apache.kafka.streams.state.HostInfo
I
- id - Variable in enum class org.apache.kafka.streams.errors.DeserializationExceptionHandler.DeserializationHandlerResponse
-
The permanent and immutable id for the used option.
- id - Variable in enum class org.apache.kafka.streams.errors.ProcessingExceptionHandler.ProcessingHandlerResponse
-
The permanent and immutable id for the used option.
- id - Variable in enum class org.apache.kafka.streams.errors.ProductionExceptionHandler.ProductionExceptionHandlerResponse
-
The permanent and immutable id for the used option.
- id - Variable in enum class org.apache.kafka.streams.errors.StreamsUncaughtExceptionHandler.StreamThreadExceptionResponse
-
The permanent and immutable id for the used option.
- id() - Method in class org.apache.kafka.streams.processor.assignment.KafkaStreamsAssignment.AssignedTask
- id() - Method in class org.apache.kafka.streams.processor.assignment.ProcessId
- id() - Method in interface org.apache.kafka.streams.processor.assignment.TaskInfo
- id() - Method in interface org.apache.kafka.streams.TopologyDescription.GlobalStore
- id() - Method in interface org.apache.kafka.streams.TopologyDescription.Subtopology
-
Internally assigned unique ID.
- identityAssignment(ApplicationState) - Static method in class org.apache.kafka.streams.processor.assignment.TaskAssignmentUtils
-
Return a "no-op" assignment that just copies the previous assignment of tasks to KafkaStreams clients
- IN_MEMORY - Enum constant in enum class org.apache.kafka.streams.kstream.Materialized.StoreType
- IN_MEMORY - Static variable in class org.apache.kafka.streams.state.BuiltInDslStoreSuppliers
- IN_MEMORY - Static variable in class org.apache.kafka.streams.StreamsConfig
-
Deprecated.
- inactivityGap() - Method in class org.apache.kafka.streams.kstream.SessionWindows
-
Return the specified gap for the session windows in milliseconds.
- init(FixedKeyProcessorContext<KIn, VOut>) - Method in class org.apache.kafka.streams.processor.api.ContextualFixedKeyProcessor
- init(FixedKeyProcessorContext<KIn, VOut>) - Method in interface org.apache.kafka.streams.processor.api.FixedKeyProcessor
-
Initialize this processor with the given context.
- init(ProcessorContext<KOut, VOut>) - Method in class org.apache.kafka.streams.processor.api.ContextualProcessor
- init(ProcessorContext<KOut, VOut>) - Method in interface org.apache.kafka.streams.processor.api.Processor
-
Initialize this processor with the given context.
- init(ProcessorContext) - Method in interface org.apache.kafka.streams.kstream.Transformer
-
Deprecated.Initialize this transformer.
- init(ProcessorContext) - Method in interface org.apache.kafka.streams.kstream.ValueTransformer
-
Deprecated.Initialize this transformer.
- init(ProcessorContext) - Method in interface org.apache.kafka.streams.kstream.ValueTransformerWithKey
-
Initialize this transformer.
- init(StateStoreContext, StateStore) - Method in interface org.apache.kafka.streams.processor.StateStore
-
Initializes this state store.
- Initializer<VAgg> - Interface in org.apache.kafka.streams.kstream
-
The
Initializer
interface for creating an initial value in aggregations. - InMemoryDslStoreSuppliers() - Constructor for class org.apache.kafka.streams.state.BuiltInDslStoreSuppliers.InMemoryDslStoreSuppliers
- inMemoryKeyValueStore(String) - Static method in class org.apache.kafka.streams.state.Stores
-
Create an in-memory
KeyValueBytesStoreSupplier
. - inMemorySessionStore(String, Duration) - Static method in class org.apache.kafka.streams.state.Stores
-
Create an in-memory
SessionBytesStoreSupplier
. - inMemoryWindowStore(String, Duration, Duration, boolean) - Static method in class org.apache.kafka.streams.state.Stores
-
Create an in-memory
WindowBytesStoreSupplier
. - inStore(String) - Static method in class org.apache.kafka.streams.query.StateQueryRequest
-
Specifies the name of the store to query.
- INTERNAL_TASK_ASSIGNOR_CLASS - Static variable in class org.apache.kafka.streams.StreamsConfig.InternalConfig
- InternalConfig() - Constructor for class org.apache.kafka.streams.StreamsConfig.InternalConfig
- InternalFixedKeyRecordFactory - Class in org.apache.kafka.streams.processor.api
- INVALID_STANDBY_TASK - Enum constant in enum class org.apache.kafka.streams.processor.assignment.TaskAssignor.AssignmentError
- InvalidStateStoreException - Exception Class in org.apache.kafka.streams.errors
-
Indicates that there was a problem when trying to access a
StateStore
. - InvalidStateStoreException(String) - Constructor for exception class org.apache.kafka.streams.errors.InvalidStateStoreException
- InvalidStateStoreException(String, Throwable) - Constructor for exception class org.apache.kafka.streams.errors.InvalidStateStoreException
- InvalidStateStoreException(Throwable) - Constructor for exception class org.apache.kafka.streams.errors.InvalidStateStoreException
- InvalidStateStorePartitionException - Exception Class in org.apache.kafka.streams.errors
-
Indicates that the specific state store being queried via
StoreQueryParameters
used a partitioning that is not assigned to this instance. - InvalidStateStorePartitionException(String) - Constructor for exception class org.apache.kafka.streams.errors.InvalidStateStorePartitionException
- InvalidStateStorePartitionException(String, Throwable) - Constructor for exception class org.apache.kafka.streams.errors.InvalidStateStorePartitionException
- IQ_CONSISTENCY_OFFSET_VECTOR_ENABLED - Static variable in class org.apache.kafka.streams.StreamsConfig.InternalConfig
- isAllPartitions() - Method in class org.apache.kafka.streams.query.StateQueryRequest
-
Whether this request should fetch from all locally available partitions.
- isChangelog() - Method in interface org.apache.kafka.streams.processor.assignment.TaskTopicPartition
- isCollectExecutionInfo() - Method in class org.apache.kafka.streams.query.QueryConfig
- isEmpty() - Method in class org.apache.kafka.streams.query.Position
- isFailure() - Method in interface org.apache.kafka.streams.query.QueryResult
-
True iff the query execution failed.
- isNamedTopology() - Method in class org.apache.kafka.streams.TopologyConfig
- isOpen() - Method in interface org.apache.kafka.streams.processor.StateStore
-
Is this store open for reading and writing
- isPaused() - Method in class org.apache.kafka.streams.KafkaStreams
- isRequireActive() - Method in class org.apache.kafka.streams.query.StateQueryRequest
-
Whether this request requires the query to execute only on active partitions.
- isRunningOrRebalancing() - Method in enum class org.apache.kafka.streams.KafkaStreams.State
- isShuttingDown() - Method in enum class org.apache.kafka.streams.KafkaStreams.State
- isSkipCache() - Method in class org.apache.kafka.streams.query.KeyQuery
-
The flag whether to skip the cache or not during query evaluation.
- isSkipCache() - Method in class org.apache.kafka.streams.query.TimestampedKeyQuery
-
The flag whether to skip the cache or not during query evaluation.
- isSlidingWindow() - Method in class org.apache.kafka.streams.state.DslWindowParams
- isSource() - Method in interface org.apache.kafka.streams.processor.assignment.TaskTopicPartition
- isStateful() - Method in interface org.apache.kafka.streams.processor.assignment.TaskInfo
- isSuccess() - Method in interface org.apache.kafka.streams.query.QueryResult
-
True iff the query was successfully executed.
- isTimestamped() - Method in class org.apache.kafka.streams.state.DslKeyValueParams
- isTimestamped() - Method in class org.apache.kafka.streams.state.DslWindowParams
- isUnbounded() - Method in class org.apache.kafka.streams.query.PositionBound
-
Returns true iff this object specifies that there is no position bound.
- isValidTransition(KafkaStreams.State) - Method in enum class org.apache.kafka.streams.KafkaStreams.State
J
- join(GlobalKTable<GK, GV>, KeyValueMapper<? super K, ? super V, ? extends GK>, ValueJoiner<? super V, ? super GV, ? extends RV>) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Join records of this stream with
GlobalKTable
's records using non-windowed inner equi join. - join(GlobalKTable<GK, GV>, KeyValueMapper<? super K, ? super V, ? extends GK>, ValueJoiner<? super V, ? super GV, ? extends RV>, Named) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Join records of this stream with
GlobalKTable
's records using non-windowed inner equi join. - join(GlobalKTable<GK, GV>, KeyValueMapper<? super K, ? super V, ? extends GK>, ValueJoinerWithKey<? super K, ? super V, ? super GV, ? extends RV>) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Join records of this stream with
GlobalKTable
's records using non-windowed inner equi join. - join(GlobalKTable<GK, GV>, KeyValueMapper<? super K, ? super V, ? extends GK>, ValueJoinerWithKey<? super K, ? super V, ? super GV, ? extends RV>, Named) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Join records of this stream with
GlobalKTable
's records using non-windowed inner equi join. - join(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 inner equi join with default serializers and deserializers. - join(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 inner equi join using theStreamJoined
instance for configuration of thekey serde
,this stream's value serde
,the other stream's value serde
, and used state stores. - join(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 inner equi join with default serializers and deserializers. - join(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 inner equi join using theStreamJoined
instance for configuration of thekey serde
,this stream's value serde
,the other stream's value serde
, and used state stores. - join(KTable<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>) - Method in interface org.apache.kafka.streams.kstream.KTable
-
Join records of this
KTable
with anotherKTable
's records using non-windowed inner equi join, with default serializers, deserializers, and state store. - join(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
with anotherKTable
's records using non-windowed inner equi join, with theMaterialized
instance for configuration of thekey serde
,the result table's value serde
, andstate store
. - join(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
with anotherKTable
's records using non-windowed inner equi join, with default serializers, deserializers, and state store. - join(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
with anotherKTable
's records using non-windowed inner equi join, with theMaterialized
instance for configuration of thekey serde
,the result table's value serde
, andstate store
. - join(KTable<K, VT>, ValueJoiner<? super V, ? super VT, ? extends VR>) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Join records of this stream with
KTable
's records using non-windowed inner equi join with default serializers and deserializers. - join(KTable<K, VT>, ValueJoiner<? super V, ? super VT, ? extends VR>, Joined<K, V, VT>) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Join records of this stream with
KTable
's records using non-windowed inner equi join with default serializers and deserializers. - join(KTable<K, VT>, ValueJoinerWithKey<? super K, ? super V, ? super VT, ? extends VR>) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Join records of this stream with
KTable
's records using non-windowed inner equi join with default serializers and deserializers. - join(KTable<K, VT>, ValueJoinerWithKey<? super K, ? super V, ? super VT, ? extends VR>, Joined<K, V, VT>) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Join records of this stream with
KTable
's records using non-windowed inner equi join with default serializers and deserializers. - join(KTable<KO, VO>, BiFunction<K, V, KO>, ValueJoiner<V, VO, VR>) - Method in interface org.apache.kafka.streams.kstream.KTable
-
Join records of this
KTable
with anotherKTable
using non-windowed inner join. - join(KTable<KO, VO>, BiFunction<K, V, KO>, ValueJoiner<V, VO, VR>, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KTable
-
Join records of this
KTable
with anotherKTable
using non-windowed inner join. - join(KTable<KO, VO>, BiFunction<K, V, KO>, ValueJoiner<V, VO, VR>, TableJoined<K, KO>) - Method in interface org.apache.kafka.streams.kstream.KTable
-
Join records of this
KTable
with anotherKTable
using non-windowed inner join, using theTableJoined
instance for optional configurations includingpartitioners
when the tables being joined use non-default partitioning, and also the base name for components of the join. - join(KTable<KO, VO>, BiFunction<K, V, KO>, ValueJoiner<V, VO, VR>, TableJoined<K, KO>, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KTable
-
Join records of this
KTable
with anotherKTable
using non-windowed inner join, using theTableJoined
instance for optional configurations includingpartitioners
when the tables being joined use non-default partitioning, and also the base name for components of the join. - join(KTable<KO, VO>, Function<V, KO>, ValueJoiner<V, VO, VR>) - Method in interface org.apache.kafka.streams.kstream.KTable
-
Join records of this
KTable
with anotherKTable
using non-windowed inner join. - join(KTable<KO, VO>, Function<V, KO>, ValueJoiner<V, VO, VR>, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KTable
-
Join records of this
KTable
with anotherKTable
using non-windowed inner join. - join(KTable<KO, VO>, Function<V, KO>, ValueJoiner<V, VO, VR>, TableJoined<K, KO>) - Method in interface org.apache.kafka.streams.kstream.KTable
-
Join records of this
KTable
with anotherKTable
using non-windowed inner join, using theTableJoined
instance for optional configurations includingpartitioners
when the tables being joined use non-default partitioning, and also the base name for components of the join. - join(KTable<KO, VO>, Function<V, KO>, ValueJoiner<V, VO, VR>, TableJoined<K, KO>, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KTable
-
Join records of this
KTable
with anotherKTable
using non-windowed inner join, using theTableJoined
instance for optional configurations includingpartitioners
when the tables being joined use non-default partitioning, and also the base name for components of the join. - Joined<K,
VLeft, - Class in org.apache.kafka.streams.kstreamVRight> -
The
Joined
class represents optional params that can be passed toKStream#join(KTable,...)
andKStream#leftJoin(KTable,...)
operations. - JoinWindows - Class in org.apache.kafka.streams.kstream
-
The window specifications used for joins.
K
- KafkaClientSupplier - Interface in org.apache.kafka.streams
-
KafkaClientSupplier
can be used to provide custom Kafka clients to aKafkaStreams
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, Time) - 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, 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, Time) - 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.CloseOptions - Class in org.apache.kafka.streams
-
Class that handles options passed in case of
KafkaStreams
instance scale down - KafkaStreams.State - Enum Class 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
-
Listen to
KafkaStreams.State
change events. - KafkaStreamsAssignment - Class in org.apache.kafka.streams.processor.assignment
-
A simple container class for the assignor to return the desired placement of active and standby tasks on KafkaStreams clients.
- KafkaStreamsAssignment.AssignedTask - Class in org.apache.kafka.streams.processor.assignment
- KafkaStreamsAssignment.AssignedTask.Type - Enum Class in org.apache.kafka.streams.processor.assignment
- KafkaStreamsState - Interface in org.apache.kafka.streams.processor.assignment
-
A read-only metadata class representing the current state of each KafkaStreams client with at least one StreamThread participating in this rebalance
- kafkaStreamsStates(boolean) - Method in interface org.apache.kafka.streams.processor.assignment.ApplicationState
- 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.FixedKeyRecord
-
The key of the record.
- key() - Method in class org.apache.kafka.streams.processor.api.Record
-
The key of the record.
- key() - Method in class org.apache.kafka.streams.query.MultiVersionedKeyQuery
-
The key that was specified for this query.
- key() - Method in class org.apache.kafka.streams.query.TimestampedKeyQuery
-
Return the key that was specified for this query.
- key() - Method in class org.apache.kafka.streams.query.VersionedKeyQuery
-
The key that was specified for this query.
- KEY - Enum constant in enum class org.apache.kafka.streams.errors.ProductionExceptionHandler.SerializationExceptionOrigin
-
Serialization exception occurred during serialization of the key.
- 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.
- KeyQuery<K,
V> - Class in org.apache.kafka.streams.query -
Interactive query for retrieving a single record based on its key.
- 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() - Method in class org.apache.kafka.streams.kstream.Joined
-
Deprecated.Since 4.0 and should not be used any longer.
- keySerde() - Method in interface org.apache.kafka.streams.processor.api.ProcessingContext
-
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.
- keySerde(Serde<K>) - Static method in class org.apache.kafka.streams.kstream.Grouped
-
Create a
Grouped
instance with the provided keySerde. - keySerde(Serde<K>) - Static method in class org.apache.kafka.streams.kstream.Joined
-
Create an instance of
Joined
with a keySerde
. - keySerde(Serde<K>) - Static method in class org.apache.kafka.streams.kstream.Produced
-
Create a Produced instance with provided keySerde.
- 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
-
A store supplier that can be used to create one or more
KeyValueStore<Bytes, byte[]>
instances of type <Bytes, byte[]>. - KeyValueIterator<K,
V> - Interface in org.apache.kafka.streams.state -
Iterator interface of
KeyValue
. - KeyValueMapper<K,
V, - Interface in org.apache.kafka.streams.kstreamVR> -
The
KeyValueMapper
interface for mapping akey-value pair
to a new value of arbitrary type. - keyValueStore() - Static method in class org.apache.kafka.streams.state.QueryableStoreTypes
-
A
QueryableStoreType
that acceptsReadOnlyKeyValueStore
. - keyValueStore(DslKeyValueParams) - Method in enum class org.apache.kafka.streams.kstream.Materialized.StoreType
- keyValueStore(DslKeyValueParams) - Method in class org.apache.kafka.streams.state.BuiltInDslStoreSuppliers.InMemoryDslStoreSuppliers
- keyValueStore(DslKeyValueParams) - Method in class org.apache.kafka.streams.state.BuiltInDslStoreSuppliers.RocksDBDslStoreSuppliers
- keyValueStore(DslKeyValueParams) - Method in interface org.apache.kafka.streams.state.DslStoreSuppliers
- KeyValueStore<K,
V> - Interface in org.apache.kafka.streams.state -
A key-value store that supports put/get/delete and range queries.
- keyValueStoreBuilder(KeyValueBytesStoreSupplier, Serde<K>, Serde<V>) - Static method in class org.apache.kafka.streams.state.Stores
-
Creates a
StoreBuilder
that can be used to build aKeyValueStore
. - KGroupedStream<K,
V> - Interface in org.apache.kafka.streams.kstream -
KGroupedStream
is an abstraction of a grouped record stream ofKeyValue
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 ofKeyValue
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.
L
- lagFor(TaskId) - Method in interface org.apache.kafka.streams.processor.assignment.KafkaStreamsState
-
Returns the total lag across all logged stores in the task.
- LagInfo - Class in org.apache.kafka.streams
-
Encapsulates information about lag, at a store partition replica (active or standby).
- latest() - Static method in class org.apache.kafka.streams.AutoOffsetReset
-
Creates an
AutoOffsetReset
instance representing "latest". - LATEST - Enum constant in enum class org.apache.kafka.streams.Topology.AutoOffsetReset
-
Deprecated.
- leaveGroup(boolean) - Method in class org.apache.kafka.streams.KafkaStreams.CloseOptions
- leftJoin(GlobalKTable<GK, GV>, KeyValueMapper<? super K, ? super V, ? extends GK>, ValueJoiner<? super V, ? super GV, ? extends RV>) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Join records of this stream with
GlobalKTable
's records using non-windowed left equi join. - leftJoin(GlobalKTable<GK, GV>, KeyValueMapper<? super K, ? super V, ? extends GK>, ValueJoiner<? super V, ? super GV, ? extends RV>, Named) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Join records of this stream with
GlobalKTable
's records using non-windowed left equi join. - leftJoin(GlobalKTable<GK, GV>, KeyValueMapper<? super K, ? super V, ? extends GK>, ValueJoinerWithKey<? super K, ? super V, ? super GV, ? extends RV>) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Join records of this stream with
GlobalKTable
's records using non-windowed left equi join. - leftJoin(GlobalKTable<GK, GV>, KeyValueMapper<? super K, ? super V, ? extends GK>, ValueJoinerWithKey<? super K, ? super V, ? super GV, ? extends RV>, Named) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Join records of this stream with
GlobalKTable
's records using non-windowed left equi join. - leftJoin(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 left equi join with default serializers and deserializers. - leftJoin(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 left equi join using theStreamJoined
instance for configuration of thekey serde
,this stream's value serde
,the other stream's value serde
, and used state stores. - leftJoin(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 left equi join with default serializers and deserializers. - leftJoin(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 left equi join using theStreamJoined
instance for configuration of thekey serde
,this stream's value serde
,the other stream's value serde
, and used state stores. - leftJoin(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 anotherKTable
's (right input) records using non-windowed left equi join, with default serializers, deserializers, and state store. - leftJoin(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 anotherKTable
's (right input) records using non-windowed left equi join, with theMaterialized
instance for configuration of thekey serde
,the result table's value serde
, andstate store
. - leftJoin(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 anotherKTable
's (right input) records using non-windowed left equi join, with default serializers, deserializers, and state store. - leftJoin(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 anotherKTable
's (right input) records using non-windowed left equi join, with theMaterialized
instance for configuration of thekey serde
,the result table's value serde
, andstate store
. - leftJoin(KTable<K, VT>, ValueJoiner<? super V, ? super VT, ? extends VR>) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Join records of this stream with
KTable
's records using non-windowed left equi join with default serializers and deserializers. - leftJoin(KTable<K, VT>, ValueJoiner<? super V, ? super VT, ? extends VR>, Joined<K, V, VT>) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Join records of this stream with
KTable
's records using non-windowed left equi join with default serializers and deserializers. - leftJoin(KTable<K, VT>, ValueJoinerWithKey<? super K, ? super V, ? super VT, ? extends VR>) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Join records of this stream with
KTable
's records using non-windowed left equi join with default serializers and deserializers. - leftJoin(KTable<K, VT>, ValueJoinerWithKey<? super K, ? super V, ? super VT, ? extends VR>, Joined<K, V, VT>) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Join records of this stream with
KTable
's records using non-windowed left equi join with default serializers and deserializers. - leftJoin(KTable<KO, VO>, BiFunction<K, V, KO>, ValueJoiner<V, VO, VR>) - Method in interface org.apache.kafka.streams.kstream.KTable
-
Join records of this
KTable
with anotherKTable
using non-windowed left join. - leftJoin(KTable<KO, VO>, BiFunction<K, V, KO>, ValueJoiner<V, VO, VR>, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KTable
-
Join records of this
KTable
with anotherKTable
using non-windowed left join. - leftJoin(KTable<KO, VO>, BiFunction<K, V, KO>, ValueJoiner<V, VO, VR>, TableJoined<K, KO>) - Method in interface org.apache.kafka.streams.kstream.KTable
-
Join records of this
KTable
with anotherKTable
using non-windowed left join, using theTableJoined
instance for optional configurations includingpartitioners
when the tables being joined use non-default partitioning, and also the base name for components of the join. - leftJoin(KTable<KO, VO>, BiFunction<K, V, KO>, ValueJoiner<V, VO, VR>, TableJoined<K, KO>, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KTable
-
Join records of this
KTable
with anotherKTable
using non-windowed left join, using theTableJoined
instance for optional configurations includingpartitioners
when the tables being joined use non-default partitioning, and also the base name for components of the join. - leftJoin(KTable<KO, VO>, Function<V, KO>, ValueJoiner<V, VO, VR>) - Method in interface org.apache.kafka.streams.kstream.KTable
-
Join records of this
KTable
with anotherKTable
using non-windowed left join. - leftJoin(KTable<KO, VO>, Function<V, KO>, ValueJoiner<V, VO, VR>, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KTable
-
Join records of this
KTable
with anotherKTable
using non-windowed left join. - leftJoin(KTable<KO, VO>, Function<V, KO>, ValueJoiner<V, VO, VR>, TableJoined<K, KO>) - Method in interface org.apache.kafka.streams.kstream.KTable
-
Join records of this
KTable
with anotherKTable
using non-windowed left join, using theTableJoined
instance for optional configurations includingpartitioners
when the tables being joined use non-default partitioning, and also the base name for components of the join. - leftJoin(KTable<KO, VO>, Function<V, KO>, ValueJoiner<V, VO, VR>, TableJoined<K, KO>, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KTable
-
Join records of this
KTable
with anotherKTable
using non-windowed left join, using theTableJoined
instance for optional configurations includingpartitioners
when the tables being joined use non-default partitioning, and also the base name for components of the join. - LockException - Exception Class in org.apache.kafka.streams.errors
-
Indicates that the state store directory lock could not be acquired because another thread holds the lock.
- LockException(String) - Constructor for exception class org.apache.kafka.streams.errors.LockException
- LockException(String, Throwable) - Constructor for exception class org.apache.kafka.streams.errors.LockException
- LockException(Throwable) - Constructor for exception class org.apache.kafka.streams.errors.LockException
- log - Static variable in interface org.apache.kafka.streams.kstream.EmitStrategy
- LOG - Static variable in interface org.apache.kafka.streams.state.RocksDBConfigSetter
- LOG_SUMMARY_INTERVAL_MS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
log.summary.interval.ms
- LogAndContinueExceptionHandler - Class in org.apache.kafka.streams.errors
-
Deserialization handler that logs a deserialization exception and then signals the processing pipeline to continue processing more records.
- LogAndContinueExceptionHandler() - Constructor for class org.apache.kafka.streams.errors.LogAndContinueExceptionHandler
- LogAndContinueProcessingExceptionHandler - Class in org.apache.kafka.streams.errors
-
Processing exception handler that logs a processing exception and then signals the processing pipeline to continue processing more records.
- LogAndContinueProcessingExceptionHandler() - Constructor for class org.apache.kafka.streams.errors.LogAndContinueProcessingExceptionHandler
- LogAndFailExceptionHandler - Class in org.apache.kafka.streams.errors
-
Deserialization handler that logs a deserialization exception and then signals the processing pipeline to stop processing more records and fail.
- LogAndFailExceptionHandler() - Constructor for class org.apache.kafka.streams.errors.LogAndFailExceptionHandler
- LogAndFailProcessingExceptionHandler - Class in org.apache.kafka.streams.errors
-
Processing exception handler that logs a processing exception and then signals the processing pipeline to stop processing more records and fail.
- LogAndFailProcessingExceptionHandler() - Constructor for class org.apache.kafka.streams.errors.LogAndFailProcessingExceptionHandler
- LogAndSkipOnInvalidTimestamp - Class in org.apache.kafka.streams.processor
-
Retrieves embedded metadata timestamps from Kafka messages.
- LogAndSkipOnInvalidTimestamp() - Constructor for class org.apache.kafka.streams.processor.LogAndSkipOnInvalidTimestamp
- logConfig() - Method in interface org.apache.kafka.streams.state.StoreBuilder
-
Returns a Map containing any log configs that will be used when creating the changelog for the
StateStore
. - loggingEnabled() - Method in interface org.apache.kafka.streams.state.StoreBuilder
- lowerBound() - Method in class org.apache.kafka.streams.query.TimestampedRangeQuery
-
The lower bound of the query, if specified.
- lruMap(String, int) - Static method in class org.apache.kafka.streams.state.Stores
-
Create a LRU Map
KeyValueBytesStoreSupplier
.
M
- 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
-
Prefix a property with
StreamsConfig.MAIN_CONSUMER_PREFIX
. - make(V, long) - Static method in class org.apache.kafka.streams.state.ValueAndTimestamp
- makeAllowNullable(V, long) - Static method in class org.apache.kafka.streams.state.ValueAndTimestamp
-
Create a new
ValueAndTimestamp
instance. - 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).
- 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>) - Method in interface org.apache.kafka.streams.kstream.KTable
-
Create a new
KTable
by transforming the value of each record in thisKTable
into a new value (with possibly a new type) in the newKTable
, 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 thisKTable
into a new value (with possibly a new type) in the newKTable
, with thekey serde
,value serde
, and the underlyingmaterialized state storage
configured in theMaterialized
instance. - 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(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 thisKTable
into a new value (with possibly a new type) in the newKTable
, with default serializers, deserializers, and state store. - 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 thisKTable
into a new value (with possibly a new type) in the newKTable
, with thekey serde
,value serde
, and the underlyingmaterialized state storage
configured in theMaterialized
instance. - 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>) - Method in interface org.apache.kafka.streams.kstream.KTable
-
Create a new
KTable
by transforming the value of each record in thisKTable
into a new value (with possibly a new type) in the newKTable
, with default serializers, deserializers, and state store. - 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 thisKTable
into a new value (with possibly a new type) in the newKTable
, with thekey serde
,value serde
, and the underlyingmaterialized state storage
configured in theMaterialized
instance. - 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(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 thisKTable
into a new value (with possibly a new type) in the newKTable
, with default serializers, deserializers, and state store. - 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 thisKTable
into a new value (with possibly a new type) in the newKTable
, with thekey serde
,value serde
, and the underlyingmaterialized state storage
configured in theMaterialized
instance. - Materialized<K,
V, - Class in org.apache.kafka.streams.kstreamS> -
Used to describe how a
StateStore
should be materialized. - Materialized.StoreType - Enum Class in org.apache.kafka.streams.kstream
- MAX_RACK_AWARE_ASSIGNMENT_TAG_KEY_LENGTH - Static variable in class org.apache.kafka.streams.StreamsConfig
- MAX_RACK_AWARE_ASSIGNMENT_TAG_LIST_SIZE - Static variable in class org.apache.kafka.streams.StreamsConfig
- MAX_RACK_AWARE_ASSIGNMENT_TAG_VALUE_LENGTH - Static variable in class org.apache.kafka.streams.StreamsConfig
- 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_TASK_IDLE_MS_DOC - Static variable in class org.apache.kafka.streams.StreamsConfig
-
Deprecated.
- MAX_WARMUP_REPLICAS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
max.warmup.replicas
- maxBufferedSize - Variable in class org.apache.kafka.streams.TopologyConfig
- maxBufferedSize - Variable in class org.apache.kafka.streams.TopologyConfig.TaskConfig
- 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.
- maxTaskIdleMs - Variable in class org.apache.kafka.streams.TopologyConfig
- maxTaskIdleMs - Variable in class org.apache.kafka.streams.TopologyConfig.TaskConfig
- maxWarmupReplicas() - Method in class org.apache.kafka.streams.processor.assignment.AssignmentConfigs
-
The maximum warmup replicas as configured via
StreamsConfig.MAX_WARMUP_REPLICAS_CONFIG
- 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.
- merge(Position) - Method in class org.apache.kafka.streams.query.Position
-
Merges the provided Position into the current instance.
- MERGE_REPARTITION_TOPICS - Static variable in class org.apache.kafka.streams.StreamsConfig
-
Config value for parameter
"topology.optimization"
for enabling the specific optimization that merges duplicated repartition topics. - 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 sameapplication ID
as this instance (i.e., all instances that belong to the same Kafka Streams application) and returnStreamsMetadata
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.ProcessingContext
-
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
-
Config value for parameter
"built.in.metrics.version"
for the latest built-in metrics version. - 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.
- MIGRATED - Enum constant in enum class org.apache.kafka.streams.processor.StandbyUpdateListener.SuspendReason
- MISSING_PROCESS_ID - Enum constant in enum class org.apache.kafka.streams.processor.assignment.TaskAssignor.AssignmentError
- MissingSourceTopicException - Exception Class in org.apache.kafka.streams.errors
- MissingSourceTopicException(String) - Constructor for exception class org.apache.kafka.streams.errors.MissingSourceTopicException
- MultiVersionedKeyQuery<K,
V> - Class in org.apache.kafka.streams.query -
Interactive query for retrieving a set of records with the same specified key and different timestamps within the specified time range.
N
- name - Variable in enum class org.apache.kafka.streams.errors.DeserializationExceptionHandler.DeserializationHandlerResponse
-
An english description for the used option.
- name - Variable in enum class org.apache.kafka.streams.errors.ProcessingExceptionHandler.ProcessingHandlerResponse
-
An english description for the used option.
- name - Variable in enum class org.apache.kafka.streams.errors.ProductionExceptionHandler.ProductionExceptionHandlerResponse
-
An english description for the used option.
- name - Variable in enum class org.apache.kafka.streams.errors.StreamsUncaughtExceptionHandler.StreamThreadExceptionResponse
-
An english description for the used option.
- name() - Method in interface org.apache.kafka.streams.processor.StateStore
-
The name of this store.
- name() - Method in class org.apache.kafka.streams.state.DslKeyValueParams
- name() - Method in class org.apache.kafka.streams.state.DslSessionParams
- name() - Method in class org.apache.kafka.streams.state.DslWindowParams
- name() - Method in interface org.apache.kafka.streams.state.StoreBuilder
-
Return the name of this state store builder.
- name() - Method in interface org.apache.kafka.streams.state.StoreSupplier
-
Return the name of this state store supplier.
- name() - Method in interface org.apache.kafka.streams.TopologyDescription.Node
-
The name of the node.
- Named - Class in org.apache.kafka.streams.kstream
- NAMED_TOPOLOGY_DELIMITER - Static variable in class org.apache.kafka.streams.processor.TaskId
- NO_OPTIMIZATION - Static variable in class org.apache.kafka.streams.StreamsConfig
-
Config value for parameter
"topology.optimization"
for disabling topology optimization - noDefaultBranch() - Method in interface org.apache.kafka.streams.kstream.BranchedKStream
-
Finalize the construction of branches without forming a default branch.
- nodes() - Method in interface org.apache.kafka.streams.TopologyDescription.Subtopology
-
All nodes of this sub-topology.
- none() - Static method in class org.apache.kafka.streams.AutoOffsetReset
-
Creates an
AutoOffsetReset
instance representing "none". - NONE - Enum constant in enum class org.apache.kafka.streams.processor.assignment.TaskAssignor.AssignmentError
- NOT_ACTIVE - Enum constant in enum class org.apache.kafka.streams.query.FailureReason
-
The query required to execute on an active task (via
StateQueryRequest.requireActive()
), but while executing the query, the task was either a Standby task, or it was an Active task not in the RUNNING state. - NOT_AVAILABLE - Static variable in class org.apache.kafka.streams.KeyQueryMetadata
-
Sentinel to indicate that the KeyQueryMetadata is currently unavailable.
- NOT_PRESENT - Enum constant in enum class org.apache.kafka.streams.query.FailureReason
-
Failure indicating that the requested store partition is not present on the local KafkaStreams instance.
- NOT_RUNNING - Enum constant in enum class org.apache.kafka.streams.KafkaStreams.State
- NOT_UP_TO_BOUND - Enum constant in enum class org.apache.kafka.streams.query.FailureReason
-
Failure indicating that the store partition is not (yet) up to the desired bound.
- notUpToBound(Position, PositionBound, Integer) - Static method in interface org.apache.kafka.streams.query.QueryResult
-
Static factory method to create a failed query result object to indicate that the store has not yet caught up to the requested position bound.
- NUM_STANDBY_REPLICAS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
num.standby.replicas
- NUM_STREAM_THREADS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
num.stream.threads
- numberOfPartitions(int) - Static method in class org.apache.kafka.streams.kstream.Repartitioned
-
Create a
Repartitioned
instance with provided number of partitions for repartition topic. - numProcessingThreads() - Method in interface org.apache.kafka.streams.processor.assignment.KafkaStreamsState
-
Returns the number of processing threads available to work on tasks for this KafkaStreams client, which represents its overall capacity for work relative to other KafkaStreams clients.
- numStandbyReplicas() - Method in class org.apache.kafka.streams.processor.assignment.AssignmentConfigs
-
The number of standby replicas as configured via
StreamsConfig.NUM_STANDBY_REPLICAS_CONFIG
O
- of() - Static method in class org.apache.kafka.streams.kstream.UnlimitedWindows
-
Return an unlimited window starting at timestamp zero.
- of(Duration) - Static method in class org.apache.kafka.streams.kstream.JoinWindows
-
Deprecated.Since 3.0. Use
JoinWindows.ofTimeDifferenceWithNoGrace(Duration)
} instead. - of(ApplicationState) - Static method in class org.apache.kafka.streams.processor.assignment.TaskAssignmentUtils.RackAwareOptimizationParams
-
Return a new config object with no overrides and the tasksToOptimize initialized to the set of all tasks in the given ApplicationState
- of(ProcessId, Set<KafkaStreamsAssignment.AssignedTask>) - Static method in class org.apache.kafka.streams.processor.assignment.KafkaStreamsAssignment
-
Construct an instance of KafkaStreamsAssignment with this processId and the given set of assigned tasks.
- of(StreamsConfig) - Static method in class org.apache.kafka.streams.processor.assignment.AssignmentConfigs
- offset() - Method in interface org.apache.kafka.streams.errors.ErrorHandlerContext
-
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.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 maxtimeDifference
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 maxtimeDifference
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.
- ON_WINDOW_CLOSE - Enum constant in enum class org.apache.kafka.streams.kstream.EmitStrategy.StrategyType
- ON_WINDOW_UPDATE - Enum constant in enum class org.apache.kafka.streams.kstream.EmitStrategy.StrategyType
- onAssignmentComputed(ConsumerPartitionAssignor.GroupAssignment, ConsumerPartitionAssignor.GroupSubscription, TaskAssignor.AssignmentError) - Method in interface org.apache.kafka.streams.processor.assignment.TaskAssignor
-
This callback can be used to observe the final assignment returned to the brokers and check for any errors that were detected while processing the returned assignment.
- onBatchLoaded(TopicPartition, String, TaskId, long, long, long) - Method in interface org.apache.kafka.streams.processor.StandbyUpdateListener
-
Method called after loading a batch of records.
- 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.
- onCommit() - Method in interface org.apache.kafka.streams.processor.CommitCallback
- 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. - onRestoreSuspended(TopicPartition, String, long) - Method in interface org.apache.kafka.streams.processor.StateRestoreListener
-
Method called when restoring the
StateStore
is suspended due to the task being migrated out of the host. - onUpdateStart(TopicPartition, String, long) - Method in interface org.apache.kafka.streams.processor.StandbyUpdateListener
-
A callback that will be invoked after registering the changelogs for each state store in a standby task.
- onUpdateSuspended(TopicPartition, String, long, long, StandbyUpdateListener.SuspendReason) - Method in interface org.apache.kafka.streams.processor.StandbyUpdateListener
-
This method is called when the corresponding standby task stops updating, for the provided reason.
- onWindowClose() - Static method in interface org.apache.kafka.streams.kstream.EmitStrategy
-
This strategy indicates that the aggregated result for a window will only be emitted when the window closes instead of when there's an update to the window.
- onWindowUpdate() - Static method in interface org.apache.kafka.streams.kstream.EmitStrategy
-
This strategy indicates that the aggregated result for a window will be emitted every time when there's an update to the window instead of when the window closes.
- OPTIMIZE - Static variable in class org.apache.kafka.streams.StreamsConfig
-
Config value for parameter
"topology.optimization"
for enabling topology optimization - optimizeRackAwareActiveTasks(TaskAssignmentUtils.RackAwareOptimizationParams, Map<ProcessId, KafkaStreamsAssignment>) - Static method in class org.apache.kafka.streams.processor.assignment.TaskAssignmentUtils
-
Optimize active task assignment for rack awareness.
- optimizeRackAwareStandbyTasks(TaskAssignmentUtils.RackAwareOptimizationParams, Map<ProcessId, KafkaStreamsAssignment>) - Static method in class org.apache.kafka.streams.processor.assignment.TaskAssignmentUtils
-
Optimize standby task assignment for rack awareness.
- org.apache.kafka.streams - package org.apache.kafka.streams
-
Provides the Kafka Streams library for building streaming data applications.
- org.apache.kafka.streams.errors - package org.apache.kafka.streams.errors
-
Provides common exception classes for Streams applications.
- org.apache.kafka.streams.kstream - package org.apache.kafka.streams.kstream
- org.apache.kafka.streams.processor - package org.apache.kafka.streams.processor
-
Provides a low-level programming model (Processor API, aka, PAPI) to express a (stateful) data flow computation over input topics.
- org.apache.kafka.streams.processor.api - package org.apache.kafka.streams.processor.api
-
Provides a low-level programming model (Processor API, aka, PAPI) to express a (stateful) data flow computation over input topics.
- org.apache.kafka.streams.processor.assignment - package org.apache.kafka.streams.processor.assignment
-
Provides classes and interfaces used to manage and assign tasks within Kafka Streams applications.
- org.apache.kafka.streams.processor.assignment.assignors - package org.apache.kafka.streams.processor.assignment.assignors
-
Provides classes for assigning tasks to stream threads.
- org.apache.kafka.streams.query - package org.apache.kafka.streams.query
-
Provides a query API (aka Interactive Queries) over state stores, for extracting data from a stateful Kafka Streams application.
- org.apache.kafka.streams.state - package org.apache.kafka.streams.state
-
Provides interfaces for managing the intermediate state of a stateful streams application.
- otherValueSerde() - Method in class org.apache.kafka.streams.kstream.Joined
-
Deprecated.Since 4.0 and should not be used any longer.
- otherValueSerde(Serde<VRight>) - Static method in class org.apache.kafka.streams.kstream.Joined
-
Create an instance of
Joined
with aother valueSerde
. - 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>, 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 theStreamJoined
instance for configuration of thekey 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) - 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, 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 theStreamJoined
instance for configuration of thekey 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 anotherKTable
'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 anotherKTable
's (right input) records using non-windowed outer equi join, with theMaterialized
instance for configuration of thekey serde
,the result table's value serde
, andstate 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 anotherKTable
'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, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KTable
-
Join records of this
KTable
(left input) with anotherKTable
's (right input) records using non-windowed outer equi join, with theMaterialized
instance for configuration of thekey serde
,the result table's value serde
, andstate store
. - overlap(Window) - Method in class org.apache.kafka.streams.kstream.Window
-
Check if the given window overlaps with this window.
P
- 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
- parseStoreType() - Method in class org.apache.kafka.streams.TopologyConfig
-
Deprecated.
- partition() - Method in interface org.apache.kafka.streams.errors.ErrorHandlerContext
-
Return the partition ID of the current input record; could be
-1
if it is not available. - 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() - 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.
- partitions(String, K, V, int) - Method in interface org.apache.kafka.streams.processor.StreamPartitioner
-
Determine the number(s) of the partition(s) to which a record with the given key and value should be sent, for the given topic and current partition count
- pause() - Method in class org.apache.kafka.streams.KafkaStreams
-
This method pauses processing for the KafkaStreams instance.
- 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
- PENDING_ERROR - Enum constant in enum class org.apache.kafka.streams.KafkaStreams.State
- PENDING_SHUTDOWN - Enum constant in enum class org.apache.kafka.streams.KafkaStreams.State
- 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
-
Create a persistent
KeyValueBytesStoreSupplier
. - persistentSessionStore(String, Duration) - Static method in class org.apache.kafka.streams.state.Stores
-
Create a persistent
SessionBytesStoreSupplier
. - persistentTimestampedKeyValueStore(String) - Static method in class org.apache.kafka.streams.state.Stores
-
Create a persistent
KeyValueBytesStoreSupplier
. - persistentTimestampedWindowStore(String, Duration, Duration, boolean) - Static method in class org.apache.kafka.streams.state.Stores
-
Create a persistent
WindowBytesStoreSupplier
. - persistentVersionedKeyValueStore(String, Duration) - Static method in class org.apache.kafka.streams.state.Stores
-
Create a persistent versioned key-value store
VersionedBytesStoreSupplier
. - persistentVersionedKeyValueStore(String, Duration, Duration) - Static method in class org.apache.kafka.streams.state.Stores
-
Create a persistent versioned key-value store
VersionedBytesStoreSupplier
. - persistentWindowStore(String, Duration, Duration, boolean) - Static method in class org.apache.kafka.streams.state.Stores
-
Create a persistent
WindowBytesStoreSupplier
. - 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 interface org.apache.kafka.streams.StreamsMetadata
-
Port on which the Streams client listens.
- position() - Method in class org.apache.kafka.streams.query.PositionBound
-
Returns the specific position of this bound.
- Position - Class in org.apache.kafka.streams.query
-
A representation of a position vector with respect to a set of topic partitions.
- PositionBound - Class in org.apache.kafka.streams.query
-
A class bounding the processing state
Position
during queries. - 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 aKeyValue
pair. - prefixScan(P, PS) - Method in interface org.apache.kafka.streams.state.ReadOnlyKeyValueStore
-
Return an iterator over all keys with the specified prefix.
- previousActiveTasks() - Method in interface org.apache.kafka.streams.processor.assignment.KafkaStreamsState
- previousStandbyTasks() - Method in interface org.apache.kafka.streams.processor.assignment.KafkaStreamsState
- prevTasksByLag(String) - Method in interface org.apache.kafka.streams.processor.assignment.KafkaStreamsState
- 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
. - PROBING_REBALANCE_INTERVAL_MS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
probing.rebalance.interval.ms
- probingRebalanceIntervalMs() - Method in class org.apache.kafka.streams.processor.assignment.AssignmentConfigs
-
The probing rebalance interval in milliseconds as configured via
StreamsConfig.PROBING_REBALANCE_INTERVAL_MS_CONFIG
- process(FixedKeyRecord<KIn, VIn>) - Method in interface org.apache.kafka.streams.processor.api.FixedKeyProcessor
-
Process the record.
- process(ProcessorSupplier<? super K, ? super V, KOut, VOut>, String...) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Process all records in this stream, one record at a time, by applying a
Processor
(provided by the givenProcessorSupplier
). - process(ProcessorSupplier<? super K, ? super V, KOut, VOut>, Named, String...) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Process all records in this stream, one record at a time, by applying a
Processor
(provided by the givenProcessorSupplier
). - process(Record<K, V>) - Method in class org.apache.kafka.streams.kstream.ForeachProcessor
-
Deprecated.
- process(Record<KIn, VIn>) - Method in interface org.apache.kafka.streams.processor.api.Processor
-
Process the record.
- processId() - Method in class org.apache.kafka.streams.processor.assignment.KafkaStreamsAssignment
- processId() - Method in interface org.apache.kafka.streams.processor.assignment.KafkaStreamsState
- ProcessId - Class in org.apache.kafka.streams.processor.assignment
-
A simple wrapper around UUID that abstracts a Process ID
- ProcessId(UUID) - Constructor for class org.apache.kafka.streams.processor.assignment.ProcessId
- PROCESSING_EXCEPTION_HANDLER_CLASS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
processing.exception.handler
- PROCESSING_EXCEPTION_HANDLER_CLASS_DOC - Static variable in class org.apache.kafka.streams.StreamsConfig
-
Deprecated.
- PROCESSING_GUARANTEE_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
processing.guarantee
- PROCESSING_THREADS_ENABLED - Static variable in class org.apache.kafka.streams.StreamsConfig.InternalConfig
- ProcessingContext - Interface in org.apache.kafka.streams.processor.api
-
Processor context interface.
- processingExceptionHandler - Variable in class org.apache.kafka.streams.TopologyConfig.TaskConfig
- processingExceptionHandler() - Method in class org.apache.kafka.streams.StreamsConfig
- ProcessingExceptionHandler - Interface in org.apache.kafka.streams.errors
-
An interface that allows user code to inspect a record that has failed processing
- ProcessingExceptionHandler.ProcessingHandlerResponse - Enum Class in org.apache.kafka.streams.errors
- processingExceptionHandlerSupplier - Variable in class org.apache.kafka.streams.TopologyConfig
- processingThreadsEnabled(Map<String, Object>) - Static method in class org.apache.kafka.streams.StreamsConfig.InternalConfig
- processor() - Method in interface org.apache.kafka.streams.TopologyDescription.GlobalStore
-
The processor node maintaining the global store.
- Processor<KIn,
VIn, - Interface in org.apache.kafka.streams.processor.apiKOut, VOut> -
A processor of key-value pair records.
- PROCESSOR_WRAPPER_CLASS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
processor.wrapper.class
- ProcessorContext<KForward,
VForward> - Interface in org.apache.kafka.streams.processor.api -
Processor context interface for
Record
. - ProcessorContext - Interface in org.apache.kafka.streams.processor
-
Processor context interface.
- processorNodeId() - Method in interface org.apache.kafka.streams.errors.ErrorHandlerContext
-
Return the current processor node ID.
- ProcessorStateException - Exception Class in org.apache.kafka.streams.errors
-
Indicates a processor state operation (e.g.
- ProcessorStateException(String) - Constructor for exception class org.apache.kafka.streams.errors.ProcessorStateException
- ProcessorStateException(String, Throwable) - Constructor for exception class org.apache.kafka.streams.errors.ProcessorStateException
- ProcessorStateException(Throwable) - Constructor for exception class org.apache.kafka.streams.errors.ProcessorStateException
- ProcessorSupplier<KIn,
VIn, - Interface in org.apache.kafka.streams.processor.apiKOut, VOut> -
A processor supplier that can create one or more
Processor
instances. - ProcessorWrapper - Interface in org.apache.kafka.streams.processor.api
-
Wrapper class that can be used to inject custom wrappers around the processors of their application topology.
- processValues(FixedKeyProcessorSupplier<? super K, ? super V, VOut>, String...) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Process all records in this stream, one record at a time, by applying a
FixedKeyProcessor
(provided by the givenFixedKeyProcessorSupplier
). - processValues(FixedKeyProcessorSupplier<? super K, ? super V, VOut>, Named, String...) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Process all records in this stream, one record at a time, by applying a
FixedKeyProcessor
(provided by the givenFixedKeyProcessorSupplier
). - Produced<K,
V> - Class in org.apache.kafka.streams.kstream -
This class is used to provide the optional parameters when producing to new topics using
KStream.to(String, 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 interface org.apache.kafka.streams.ThreadMetadata
-
Client IDs of the Kafka producers used by the stream thread.
- producerInstanceIds() - Method in interface org.apache.kafka.streams.ClientInstanceIds
-
Returns the
client instance id
of the producers. - producerPrefix(String) - Static method in class org.apache.kafka.streams.StreamsConfig
-
Prefix a property with
StreamsConfig.PRODUCER_PREFIX
. - PRODUCTION_EXCEPTION_HANDLER_CLASS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
production.exception.handler
- productionExceptionHandler() - 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 Class in org.apache.kafka.streams.errors
- ProductionExceptionHandler.SerializationExceptionOrigin - Enum Class in org.apache.kafka.streams.errors
- PROMOTED - Enum constant in enum class org.apache.kafka.streams.processor.StandbyUpdateListener.SuspendReason
- punctuate(long) - Method in interface org.apache.kafka.streams.processor.Punctuator
-
Perform the scheduled periodic operation.
- PunctuationType - Enum Class in org.apache.kafka.streams.processor
-
Controls what notion of time is used for punctuation scheduled via
schedule
: STREAM_TIME - uses "stream time", which is advanced by the processing of messages in accordance with the timestamp as extracted by theTimestampExtractor
in use. - Punctuator - Interface in org.apache.kafka.streams.processor
-
A functional interface used as an argument to
ProcessorContext.schedule(Duration, PunctuationType, Punctuator)
. - put(K, V) - Method in interface org.apache.kafka.streams.state.KeyValueStore
-
Update the value associated with this key.
- put(K, V, long) - Method in interface org.apache.kafka.streams.state.VersionedKeyValueStore
-
Add a new record version associated with the specified key and timestamp.
- 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
- put(Bytes, byte[], long) - Method in interface org.apache.kafka.streams.state.VersionedBytesStore
-
The analog of
VersionedKeyValueStore.put(Object, Object, long)
. - 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_RETURN_CODE_NOT_PUT - Static variable in interface org.apache.kafka.streams.state.VersionedKeyValueStore
- PUT_RETURN_CODE_VALID_TO_UNDEFINED - Static variable in interface org.apache.kafka.streams.state.VersionedKeyValueStore
- 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.
Q
- query(Query<R>, PositionBound, QueryConfig) - Method in interface org.apache.kafka.streams.processor.StateStore
-
Execute a query.
- query(StateQueryRequest<R>) - Method in class org.apache.kafka.streams.KafkaStreams
-
Run an interactive query against a state store.
- Query<R> - Interface in org.apache.kafka.streams.query
-
Marker interface that all interactive queries must implement (see
KafkaStreams.query(StateQueryRequest)
). - queryableStoreName() - Method in interface org.apache.kafka.streams.kstream.GlobalKTable
-
Get the name of the local state store that can be used to query this
GlobalKTable
. - queryableStoreName() - Method in interface org.apache.kafka.streams.kstream.KTable
-
Get the name of the local state store used that can be used to query this
KTable
. - queryableStoreType() - Method in class org.apache.kafka.streams.StoreQueryParameters
-
Get the queryable store type for which key is queried by the user.
- QueryableStoreType<T> - Interface in org.apache.kafka.streams.state
-
Used to enable querying of custom
StateStore
types via theKafkaStreams
API. - QueryableStoreTypes - Class in org.apache.kafka.streams.state
-
Provides access to the
QueryableStoreType
s provided withKafkaStreams
. - QueryableStoreTypes() - Constructor for class org.apache.kafka.streams.state.QueryableStoreTypes
- QueryableStoreTypes.KeyValueStoreType<K,
V> - Class in org.apache.kafka.streams.state - QueryableStoreTypes.SessionStoreType<K,
V> - Class in org.apache.kafka.streams.state - QueryableStoreTypes.WindowStoreType<K,
V> - Class in org.apache.kafka.streams.state - QueryConfig - Class in org.apache.kafka.streams.query
-
Runtime configuration parameters
- QueryConfig(boolean) - Constructor for class org.apache.kafka.streams.query.QueryConfig
- queryMetadataForKey(String, K, Serializer<K>) - Method in class org.apache.kafka.streams.KafkaStreams
-
Finds the metadata containing the active hosts and standby hosts where the key being queried would reside.
- queryMetadataForKey(String, K, StreamPartitioner<? super K, ?>) - Method in class org.apache.kafka.streams.KafkaStreams
-
Finds the metadata containing the active hosts and standby hosts where the key being queried would reside.
- QueryResult<R> - Interface in org.apache.kafka.streams.query
-
Container for a single partition's result when executing a
StateQueryRequest
.
R
- RACK_AWARE_ASSIGNMENT_NON_OVERLAP_COST_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
rack.aware.assignment.non_overlap_cost
- RACK_AWARE_ASSIGNMENT_NON_OVERLAP_COST_DOC - Static variable in class org.apache.kafka.streams.StreamsConfig
-
Deprecated.
- RACK_AWARE_ASSIGNMENT_STRATEGY_BALANCE_SUBTOPOLOGY - Static variable in class org.apache.kafka.streams.StreamsConfig
- RACK_AWARE_ASSIGNMENT_STRATEGY_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
rack.aware.assignment.strategy
- RACK_AWARE_ASSIGNMENT_STRATEGY_DOC - Static variable in class org.apache.kafka.streams.StreamsConfig
-
Deprecated.
- RACK_AWARE_ASSIGNMENT_STRATEGY_MIN_TRAFFIC - Static variable in class org.apache.kafka.streams.StreamsConfig
- RACK_AWARE_ASSIGNMENT_STRATEGY_NONE - Static variable in class org.apache.kafka.streams.StreamsConfig
- RACK_AWARE_ASSIGNMENT_TAGS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
rack.aware.assignment.tags
- RACK_AWARE_ASSIGNMENT_TRAFFIC_COST_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
rack.aware.assignment.traffic_cost
- RACK_AWARE_ASSIGNMENT_TRAFFIC_COST_DOC - Static variable in class org.apache.kafka.streams.StreamsConfig
-
Deprecated.
- rackAwareAssignmentStrategy() - Method in class org.apache.kafka.streams.processor.assignment.AssignmentConfigs
-
The rack-aware assignment strategy as configured via
StreamsConfig.RACK_AWARE_ASSIGNMENT_STRATEGY_CONFIG
- rackAwareAssignmentTags() - Method in class org.apache.kafka.streams.processor.assignment.AssignmentConfigs
-
The rack-aware assignment tags as configured via
StreamsConfig.RACK_AWARE_ASSIGNMENT_TAGS_CONFIG
- rackAwareNonOverlapCost() - Method in class org.apache.kafka.streams.processor.assignment.AssignmentConfigs
-
The rack-aware assignment non-overlap cost as configured via
StreamsConfig.RACK_AWARE_ASSIGNMENT_NON_OVERLAP_COST_CONFIG
- rackAwareTrafficCost() - Method in class org.apache.kafka.streams.processor.assignment.AssignmentConfigs
-
The rack-aware assignment traffic cost as configured via
StreamsConfig.RACK_AWARE_ASSIGNMENT_TRAFFIC_COST_CONFIG
- rackId() - Method in interface org.apache.kafka.streams.processor.assignment.KafkaStreamsState
- rackIds() - Method in interface org.apache.kafka.streams.processor.assignment.TaskTopicPartition
- randomProcessId() - Static method in class org.apache.kafka.streams.processor.assignment.ProcessId
- range(K, K) - Method in interface org.apache.kafka.streams.state.ReadOnlyKeyValueStore
-
Get an iterator over a given range of keys.
- RangeQuery<K,
V> - Class in org.apache.kafka.streams.query -
Interactive query for issuing range queries and scans over KeyValue stores.
- 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.
- 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.
- REBALANCING - Enum constant in enum class org.apache.kafka.streams.KafkaStreams.State
- 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 viaProcessorContext
. - 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.
- 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.
- RecordContext - Interface in org.apache.kafka.streams.processor
-
The context associated with the current record being processed by a
Processor
- recordMetadata() - Method in interface org.apache.kafka.streams.processor.api.ProcessingContext
-
Return the metadata of the current record if available.
- recordMetadata() - Method in interface org.apache.kafka.streams.processor.StateStoreContext
-
Return the metadata of the current topic/partition/offset 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>) - 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>, 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>, 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>, 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) - 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.TimeWindowedKStream
-
Combine the values of records in this stream by the grouped key and defined windows.
- 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>, 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>, 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.
- reduce(Reducer<V>, Reducer<V>) - Method in interface org.apache.kafka.streams.kstream.KGroupedTable
- reduce(Reducer<V>, Reducer<V>, Materialized<K, V, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KGroupedTable
- reduce(Reducer<V>, Reducer<V>, Named, Materialized<K, V, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KGroupedTable
- 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.
- register(StateStore, StateRestoreCallback, CommitCallback) - 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.
- removeTask(KafkaStreamsAssignment.AssignedTask) - Method in class org.apache.kafka.streams.processor.assignment.KafkaStreamsAssignment
- 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 default partitioning strategy. - 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 usingkey serde
,value serde
,StreamPartitioner
, number of partitions, and topic name part as defined byRepartitioned
. - REPARTITION_PURGE_INTERVAL_MS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
repartition.purge.interval.ms
- Repartitioned<K,
V> - Class in org.apache.kafka.streams.kstream -
This class is used to provide the optional parameters for internal repartition topics.
- REPLACE_THREAD - Enum constant in enum class org.apache.kafka.streams.errors.StreamsUncaughtExceptionHandler.StreamThreadExceptionResponse
-
Replace the failed thread with a new one.
- 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
- requireActive() - Method in class org.apache.kafka.streams.query.StateQueryRequest
-
Specifies that this query should only run on partitions for which this instance is the leader (aka "active").
- resolveDslStoreSuppliers() - Method in class org.apache.kafka.streams.TopologyConfig
- 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 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
-
Prefix a property with
StreamsConfig.RESTORE_CONSUMER_PREFIX
. - resultOrder() - Method in class org.apache.kafka.streams.query.MultiVersionedKeyQuery
-
The order of the returned records by timestamp.
- resultOrder() - Method in class org.apache.kafka.streams.query.RangeQuery
-
Determines if the serialized byte[] of the keys in ascending or descending or unordered order.
- resultOrder() - Method in class org.apache.kafka.streams.query.TimestampedRangeQuery
-
Determines if the serialized byte[] of the keys in ascending or descending or unordered order.
- ResultOrder - Enum Class in org.apache.kafka.streams.query
- resume() - Method in class org.apache.kafka.streams.KafkaStreams
-
This method resumes processing for the KafkaStreams instance.
- retainDuplicates() - Method in class org.apache.kafka.streams.state.DslWindowParams
- retainDuplicates() - Method in interface org.apache.kafka.streams.state.WindowBytesStoreSupplier
-
Whether or not this store is retaining duplicate keys.
- retentionPeriod() - Method in class org.apache.kafka.streams.state.DslSessionParams
- retentionPeriod() - Method in class org.apache.kafka.streams.state.DslWindowParams
- 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. - RETRY - Enum constant in enum class org.apache.kafka.streams.errors.ProductionExceptionHandler.ProductionExceptionHandlerResponse
-
Retry the failed operation.
- RETRY_BACKOFF_MS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
retry.backoff.ms
- REUSE_KTABLE_SOURCE_TOPICS - Static variable in class org.apache.kafka.streams.StreamsConfig
-
Config value for parameter
"topology.optimization"
for enabling the specific optimization that reuses source topic as changelog topic for KTables. - 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.
- ROCKS_DB - Enum constant in enum class org.apache.kafka.streams.kstream.Materialized.StoreType
- ROCKS_DB - Static variable in class org.apache.kafka.streams.state.BuiltInDslStoreSuppliers
- ROCKS_DB - Static variable in class org.apache.kafka.streams.StreamsConfig
-
Deprecated.
- 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.
- RocksDBDslStoreSuppliers() - Constructor for class org.apache.kafka.streams.state.BuiltInDslStoreSuppliers.RocksDBDslStoreSuppliers
- Rules of forming the resulting map - Search tag in interface org.apache.kafka.streams.kstream.BranchedKStream
- Section
- RUNNING - Enum constant in enum class org.apache.kafka.streams.KafkaStreams.State
S
- schedule(Duration, PunctuationType, Punctuator) - Method in interface org.apache.kafka.streams.processor.api.ProcessingContext
-
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
-
A store supplier that can be used to create one or more
SessionStore<Byte, byte[]>
instances. - sessionStore() - Static method in class org.apache.kafka.streams.state.QueryableStoreTypes
-
A
QueryableStoreType
that acceptsReadOnlySessionStore
. - sessionStore(DslSessionParams) - Method in enum class org.apache.kafka.streams.kstream.Materialized.StoreType
- sessionStore(DslSessionParams) - Method in class org.apache.kafka.streams.state.BuiltInDslStoreSuppliers.InMemoryDslStoreSuppliers
- sessionStore(DslSessionParams) - Method in class org.apache.kafka.streams.state.BuiltInDslStoreSuppliers.RocksDBDslStoreSuppliers
- sessionStore(DslSessionParams) - Method in interface org.apache.kafka.streams.state.DslStoreSuppliers
- 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
-
Creates a
StoreBuilder
that can be used to build aSessionStore
. - SessionWindowedCogroupedKStream<K,
V> - Interface in org.apache.kafka.streams.kstream -
SessionWindowedCogroupKStream
is an abstraction of a windowed record stream ofKeyValue
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 ofKeyValue
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.
- setGlobalResult(QueryResult<R>) - Method in class org.apache.kafka.streams.query.StateQueryResult
-
Set the result for a global store query.
- 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
- setPosition(Position) - Method in interface org.apache.kafka.streams.query.QueryResult
-
Used by stores to report what exact position in the store's history it was at when it executed the query.
- setStandbyUpdateListener(StandbyUpdateListener) - Method in class org.apache.kafka.streams.KafkaStreams
-
Set the listener which is triggered whenever a standby task is updated
- setStateListener(KafkaStreams.StateListener) - Method in class org.apache.kafka.streams.KafkaStreams
-
An app can set a single
KafkaStreams.StateListener
so that the app is notified when state changes. - setTaskId(TaskId) - Method in exception class org.apache.kafka.streams.errors.StreamsException
- setUncaughtExceptionHandler(StreamsUncaughtExceptionHandler) - Method in class org.apache.kafka.streams.KafkaStreams
-
Set the handler invoked when an internal
stream thread
throws an unexpected exception. - SHUTDOWN_APPLICATION - Enum constant in enum class org.apache.kafka.streams.errors.StreamsUncaughtExceptionHandler.StreamThreadExceptionResponse
-
Try to shut down the whole application.
- SHUTDOWN_CLIENT - Enum constant in enum class org.apache.kafka.streams.errors.StreamsUncaughtExceptionHandler.StreamThreadExceptionResponse
-
Shut down the client.
- 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
- SINGLE_STORE_SELF_JOIN - Static variable in class org.apache.kafka.streams.StreamsConfig
-
Config value for parameter
"topology.optimization"
for enabling the optimization that optimizes inner stream-stream joins into self-joins when both arguments are the same stream. - 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.
- skipCache() - Method in class org.apache.kafka.streams.query.KeyQuery
-
Specifies that the cache should be skipped during query evaluation.
- skipCache() - Method in class org.apache.kafka.streams.query.TimestampedKeyQuery
-
Specifies that the cache should be skipped during query evaluation.
- 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.
- STANDBY - Enum constant in enum class org.apache.kafka.streams.processor.assignment.KafkaStreamsAssignment.AssignedTask.Type
- standbyHosts() - Method in class org.apache.kafka.streams.KeyQueryMetadata
-
Get the Kafka Streams instances that host the key as standbys.
- 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 interface org.apache.kafka.streams.ThreadMetadata
-
Metadata of the standby tasks assigned to the stream thread.
- standbyTopicPartitions() - Method in interface org.apache.kafka.streams.StreamsMetadata
-
Source topic partitions for which the instance acts as standby.
- StandbyUpdateListener - Interface in org.apache.kafka.streams.processor
- StandbyUpdateListener.SuspendReason - Enum Class in org.apache.kafka.streams.processor
- 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.
- 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() - Method in class org.apache.kafka.streams.KafkaStreams
-
Return the current
KafkaStreams.State
of thisKafkaStreams
instance. - 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
- STATE_UPDATER_ENABLED - Static variable in class org.apache.kafka.streams.StreamsConfig.InternalConfig
- stateDir() - Method in interface org.apache.kafka.streams.processor.api.ProcessingContext
-
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.
- statefulTasksToLagSums() - Method in interface org.apache.kafka.streams.processor.assignment.KafkaStreamsState
-
Returns a collection containing all (and only) stateful tasks in the topology by
TaskId
, mapped to its "offset lag sum". - StateQueryRequest<R> - Class in org.apache.kafka.streams.query
-
The request object for Interactive Queries.
- StateQueryRequest.InStore - Class in org.apache.kafka.streams.query
-
A progressive builder interface for creating
StoreQueryRequest
s. - StateQueryResult<R> - Class in org.apache.kafka.streams.query
-
The response object for interactive queries.
- StateQueryResult() - Constructor for class org.apache.kafka.streams.query.StateQueryResult
- 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.
- STATESTORE_CACHE_MAX_BYTES_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
statestore.cache.max.bytes
- STATESTORE_CACHE_MAX_BYTES_DOC - Static variable in class org.apache.kafka.streams.StreamsConfig
-
Deprecated.
- StateStoreContext - Interface in org.apache.kafka.streams.processor
-
State store context interface.
- StateStoreMigratedException - Exception Class in org.apache.kafka.streams.errors
-
Indicates that the state store being queried is closed although the Kafka Streams state is
RUNNING
orREBALANCING
. - StateStoreMigratedException(String) - Constructor for exception class org.apache.kafka.streams.errors.StateStoreMigratedException
- StateStoreMigratedException(String, Throwable) - Constructor for exception class org.apache.kafka.streams.errors.StateStoreMigratedException
- stateStoreNames() - Method in interface org.apache.kafka.streams.processor.assignment.TaskInfo
- stateStoreNames() - Method in interface org.apache.kafka.streams.StreamsMetadata
-
Names of the state stores assigned to active tasks of the Streams client.
- StateStoreNotAvailableException - Exception Class in org.apache.kafka.streams.errors
-
Indicates that the state store being queried is already closed.
- StateStoreNotAvailableException(String) - Constructor for exception class org.apache.kafka.streams.errors.StateStoreNotAvailableException
- StateStoreNotAvailableException(String, Throwable) - Constructor for exception class org.apache.kafka.streams.errors.StateStoreNotAvailableException
- stateUpdaterEnabled(Map<String, Object>) - Static method in class org.apache.kafka.streams.StreamsConfig.InternalConfig
- StickyTaskAssignor - Class in org.apache.kafka.streams.processor.assignment.assignors
- StickyTaskAssignor() - Constructor for class org.apache.kafka.streams.processor.assignment.assignors.StickyTaskAssignor
- StickyTaskAssignor(boolean) - Constructor for class org.apache.kafka.streams.processor.assignment.assignors.StickyTaskAssignor
- store(StoreQueryParameters<T>) - Method in class org.apache.kafka.streams.KafkaStreams
-
Get a facade wrapping the local
StateStore
instances with the providedStoreQueryParameters
. - STORE_EXCEPTION - Enum constant in enum class org.apache.kafka.streams.query.FailureReason
-
The store that handled the query got an exception during query execution.
- StoreBuilder<T> - Interface in org.apache.kafka.streams.state
-
Build a
StateStore
wrapped with optional caching and logging. - 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() - Method in interface org.apache.kafka.streams.TopologyDescription.Processor
-
The names of all connected stores.
- 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
- StoreSupplier<T> - Interface in org.apache.kafka.streams.state
-
A state store supplier which can create one or more
StateStore
instances. - storeType - Variable in class org.apache.kafka.streams.TopologyConfig
- 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. - STREAM_TIME - Enum constant in enum class org.apache.kafka.streams.processor.PunctuationType
- StreamJoined<K,
V1, - Class in org.apache.kafka.streams.kstreamV2> -
Class used to configure the name of the join processor, the repartition topic name, state stores or state store names in Stream-Stream join.
- 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
provides the high-level Kafka Streams DSL to specify a Kafka Streams topology. - StreamsBuilder() - Constructor for class org.apache.kafka.streams.StreamsBuilder
- StreamsBuilder(TopologyConfig) - Constructor for class org.apache.kafka.streams.StreamsBuilder
-
Create a
StreamsBuilder
instance. - StreamsConfig - Class in org.apache.kafka.streams
-
Configuration for a
KafkaStreams
instance. - StreamsConfig(Map<?, ?>) - Constructor for class org.apache.kafka.streams.StreamsConfig
-
Create a new
StreamsConfig
using the given properties. - StreamsConfig.InternalConfig - Class in org.apache.kafka.streams
- StreamsException - Exception Class in org.apache.kafka.streams.errors
-
StreamsException
is the top-level exception type generated by Kafka Streams, and indicates errors have occurred during aStreamThread's
processing. - StreamsException(String) - Constructor for exception class org.apache.kafka.streams.errors.StreamsException
- StreamsException(String, Throwable) - Constructor for exception class org.apache.kafka.streams.errors.StreamsException
- StreamsException(String, Throwable, TaskId) - Constructor for exception class org.apache.kafka.streams.errors.StreamsException
- StreamsException(String, TaskId) - Constructor for exception class org.apache.kafka.streams.errors.StreamsException
- StreamsException(Throwable) - Constructor for exception class org.apache.kafka.streams.errors.StreamsException
- StreamsException(Throwable, TaskId) - Constructor for exception class org.apache.kafka.streams.errors.StreamsException
- 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 sameapplication ID
as this instance (i.e., all instances that belong to the same Kafka Streams application) and that contain aStateStore
with the givenstoreName
and returnStreamsMetadata
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 Class 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 class org.apache.kafka.streams.errors.StreamsNotStartedException
- StreamsNotStartedException(String, Throwable) - Constructor for exception class org.apache.kafka.streams.errors.StreamsNotStartedException
- StreamsRebalancingException - Exception Class 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 class org.apache.kafka.streams.errors.StreamsRebalancingException
- StreamsRebalancingException(String, Throwable) - Constructor for exception class org.apache.kafka.streams.errors.StreamsRebalancingException
- StreamsStoppedException - Exception Class in org.apache.kafka.streams.errors
-
Indicates that Kafka Streams is in a terminating or terminal state, such as
KafkaStreams.State.PENDING_SHUTDOWN
,KafkaStreams.State.PENDING_ERROR
,KafkaStreams.State.NOT_RUNNING
, orKafkaStreams.State.ERROR
. - StreamsStoppedException(String) - Constructor for exception class org.apache.kafka.streams.errors.StreamsStoppedException
- StreamsStoppedException(String, Throwable) - Constructor for exception class org.apache.kafka.streams.errors.StreamsStoppedException
- StreamsUncaughtExceptionHandler - Interface in org.apache.kafka.streams.errors
- StreamsUncaughtExceptionHandler.StreamThreadExceptionResponse - Enum Class 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> - 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.
T
- 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, 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, 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 -
The
TableJoined
class represents optional parameters that can be passed toKTable#join(KTable,Function,...)
andKTable#leftJoin(KTable,Function,...)
operations, for foreign key joins. - TASK_ASSIGNOR_CLASS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
task.assignor.class
- 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
-
Deprecated.
- TaskAssignment(Collection<KafkaStreamsAssignment>) - Constructor for class org.apache.kafka.streams.processor.assignment.TaskAssignor.TaskAssignment
- TaskAssignmentException - Exception Class in org.apache.kafka.streams.errors
-
Indicates a run time error incurred while trying to assign
stream tasks
tothreads
. - TaskAssignmentException(String) - Constructor for exception class org.apache.kafka.streams.errors.TaskAssignmentException
- TaskAssignmentException(String, Throwable) - Constructor for exception class org.apache.kafka.streams.errors.TaskAssignmentException
- TaskAssignmentException(Throwable) - Constructor for exception class org.apache.kafka.streams.errors.TaskAssignmentException
- TaskAssignmentUtils - Class in org.apache.kafka.streams.processor.assignment
-
A set of utilities to help implement task assignment via the
TaskAssignor
- TaskAssignmentUtils.MoveStandbyTaskPredicate - Interface in org.apache.kafka.streams.processor.assignment
- TaskAssignmentUtils.RackAwareOptimizationParams - Class in org.apache.kafka.streams.processor.assignment
-
A simple config container for necessary parameters and optional overrides to apply when running the active or standby task rack-aware optimizations.
- TaskAssignor - Interface in org.apache.kafka.streams.processor.assignment
-
A TaskAssignor is responsible for creating a TaskAssignment from a given
ApplicationState
. - TaskAssignor.AssignmentError - Enum Class in org.apache.kafka.streams.processor.assignment
-
NONE: no error detected ACTIVE_TASK_ASSIGNED_MULTIPLE_TIMES: multiple KafkaStreams clients assigned with the same active task INVALID_STANDBY_TASK: stateless task assigned as a standby task MISSING_PROCESS_ID: ProcessId present in the input ApplicationState was not present in the output TaskAssignment UNKNOWN_PROCESS_ID: unrecognized ProcessId not matching any of the participating consumers UNKNOWN_TASK_ID: unrecognized TaskId not matching any of the tasks to be assigned
- TaskAssignor.TaskAssignment - Class in org.apache.kafka.streams.processor.assignment
-
Wrapper class for the final assignment of active and standbys tasks to individual KafkaStreams clients.
- TaskCorruptedException - Exception Class in org.apache.kafka.streams.errors
-
Indicates a specific task is corrupted and need to be re-initialized.
- TaskCorruptedException(Set<TaskId>) - Constructor for exception class org.apache.kafka.streams.errors.TaskCorruptedException
- TaskCorruptedException(Set<TaskId>, InvalidOffsetException) - Constructor for exception class org.apache.kafka.streams.errors.TaskCorruptedException
- taskId() - Method in interface org.apache.kafka.streams.errors.ErrorHandlerContext
-
Return the task ID.
- taskId() - Method in exception class org.apache.kafka.streams.errors.StreamsException
- taskId() - Method in interface org.apache.kafka.streams.processor.api.ProcessingContext
-
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() - Method in interface org.apache.kafka.streams.TaskMetadata
-
Task ID of the task.
- TaskId - Class in org.apache.kafka.streams.processor
-
The task ID representation composed as subtopology 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
- TaskIdFormatException - Exception Class 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 class org.apache.kafka.streams.errors.TaskIdFormatException
- TaskIdFormatException(String, Throwable) - Constructor for exception class org.apache.kafka.streams.errors.TaskIdFormatException
- TaskIdFormatException(Throwable) - Constructor for exception class org.apache.kafka.streams.errors.TaskIdFormatException
- TaskInfo - Interface in org.apache.kafka.streams.processor.assignment
-
A simple container class corresponding to a given
TaskId
. - TaskMetadata - Interface in org.apache.kafka.streams
-
Metadata of a task.
- TaskMigratedException - Exception Class in org.apache.kafka.streams.errors
-
Indicates that all tasks belongs to the thread have migrated to another thread.
- TaskMigratedException(String) - Constructor for exception class org.apache.kafka.streams.errors.TaskMigratedException
- TaskMigratedException(String, Throwable) - Constructor for exception class org.apache.kafka.streams.errors.TaskMigratedException
- tasks() - Method in class org.apache.kafka.streams.processor.assignment.KafkaStreamsAssignment
- taskTimeoutMs - Variable in class org.apache.kafka.streams.TopologyConfig.TaskConfig
- taskTimeoutMs - Variable in class org.apache.kafka.streams.TopologyConfig
- TaskTopicPartition - Interface in org.apache.kafka.streams.processor.assignment
-
This is a simple container class used during the assignment process to distinguish TopicPartitions type.
- 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.
- ThreadMetadata - Interface in org.apache.kafka.streams
-
Metadata of a stream thread.
- threadName() - Method in interface org.apache.kafka.streams.ThreadMetadata
-
Name of the stream thread
- threadState() - Method in interface org.apache.kafka.streams.ThreadMetadata
-
State of the stream thread
- timeCurrentIdlingStarted() - Method in interface org.apache.kafka.streams.TaskMetadata
-
Time task idling started.
- timeDifferenceMs() - Method in class org.apache.kafka.streams.kstream.SlidingWindows
- timeout(Duration) - Method in class org.apache.kafka.streams.KafkaStreams.CloseOptions
- timestamp() - Method in interface org.apache.kafka.streams.errors.ErrorHandlerContext
-
Return the current timestamp; could be
-1
if it is not available. - timestamp() - Method in class org.apache.kafka.streams.processor.api.FixedKeyRecord
-
The timestamp of the record.
- 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() - Method in class org.apache.kafka.streams.state.ValueAndTimestamp
- timestamp() - Method in class org.apache.kafka.streams.state.VersionedRecord
- TIMESTAMP_SIZE - Static variable in class org.apache.kafka.streams.state.StateSerdes
- TimestampedBytesStore - Interface in org.apache.kafka.streams.state
- TimestampedKeyQuery<K,
V> - Class in org.apache.kafka.streams.query -
Interactive query for retrieving a single record based on its key from
TimestampedKeyValueStore
- timestampedKeyValueStore() - Static method in class org.apache.kafka.streams.state.QueryableStoreTypes
-
A
QueryableStoreType
that acceptsReadOnlyKeyValueStore<K, ValueAndTimestamp<V>>
. - 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
-
Creates a
StoreBuilder
that can be used to build aTimestampedKeyValueStore
. - TimestampedRangeQuery<K,
V> - Class in org.apache.kafka.streams.query -
Interactive query for issuing range queries and scans over
TimestampedKeyValueStore
- timestampedWindowStore() - Static method in class org.apache.kafka.streams.state.QueryableStoreTypes
-
A
QueryableStoreType
that acceptsReadOnlyWindowStore<K, ValueAndTimestamp<V>>
. - 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
-
Creates a
StoreBuilder
that can be used to build aTimestampedWindowStore
. - timestampExtractor - Variable in class org.apache.kafka.streams.TopologyConfig.TaskConfig
- 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
. - timestampExtractorSupplier - Variable in class org.apache.kafka.streams.TopologyConfig
- TimeWindowedCogroupedKStream<K,
V> - Interface in org.apache.kafka.streams.kstream -
TimeWindowedCogroupKStream
is an abstraction of a windowed record stream ofKeyValue
pairs. - TimeWindowedDeserializer<T> - Class in org.apache.kafka.streams.kstream
- TimeWindowedDeserializer() - Constructor for class org.apache.kafka.streams.kstream.TimeWindowedDeserializer
- 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 ofKeyValue
pairs. - TimeWindowedSerde() - Constructor for class org.apache.kafka.streams.kstream.WindowedSerdes.TimeWindowedSerde
- TimeWindowedSerde(Serde<T>, long) - Constructor for class org.apache.kafka.streams.kstream.WindowedSerdes.TimeWindowedSerde
- 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 default partitioning strategy.
- 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 default partitioning strategy.
- 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
-
This class is used to provide the optional parameters when sending output records to downstream processor using
ProcessorContext.forward(Object, Object, 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.errors.ErrorHandlerContext
-
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.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.
- TOPIC_PREFIX_ALTERNATIVE - Static variable in class org.apache.kafka.streams.StreamsConfig.InternalConfig
- 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. - 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.
- topicPartition() - Method in interface org.apache.kafka.streams.processor.assignment.TaskTopicPartition
- topicPartitions() - Method in interface org.apache.kafka.streams.processor.assignment.TaskInfo
- 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 - Class in org.apache.kafka.streams
-
A logical representation of a
ProcessorTopology
. - Topology() - Constructor for class org.apache.kafka.streams.Topology
- Topology(TopologyConfig) - Constructor for class org.apache.kafka.streams.Topology
- TOPOLOGY_OPTIMIZATION_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
topology.optimization
- Topology.AutoOffsetReset - Enum Class in org.apache.kafka.streams
-
Deprecated.Since 4.0. Use
AutoOffsetReset
instead. - TopologyConfig - Class in org.apache.kafka.streams
-
Streams configs that apply at the topology level.
- TopologyConfig(String, StreamsConfig, Properties) - Constructor for class org.apache.kafka.streams.TopologyConfig
- TopologyConfig(StreamsConfig) - Constructor for class org.apache.kafka.streams.TopologyConfig
- TopologyConfig.TaskConfig - Class in org.apache.kafka.streams
- TopologyDescription - Interface in org.apache.kafka.streams
-
A meta representation of a
topology
. - TopologyDescription.GlobalStore - Interface in org.apache.kafka.streams
-
Represents a
global store
. - 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
-
A connected sub-graph of a
Topology
. - TopologyException - Exception Class in org.apache.kafka.streams.errors
-
Indicates a pre run time error occurred while parsing the
logical topology
to construct thephysical processor topology
. - TopologyException(String) - Constructor for exception class org.apache.kafka.streams.errors.TopologyException
- TopologyException(String, Throwable) - Constructor for exception class org.apache.kafka.streams.errors.TopologyException
- TopologyException(Throwable) - Constructor for exception class org.apache.kafka.streams.errors.TopologyException
- topologyName - Variable in class org.apache.kafka.streams.TopologyConfig
- topologyName() - Method in class org.apache.kafka.streams.processor.TaskId
-
Experimental feature -- will return null
- topologyOverrides - Variable in class org.apache.kafka.streams.TopologyConfig
- toStream() - 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
-
Convert this changelog stream to a
KStream
using the givenKeyValueMapper
to select the new key. - toStream(KeyValueMapper<? super K, ? super V, ? extends KR>, Named) - Method in interface org.apache.kafka.streams.kstream.KTable
-
Convert this changelog stream to a
KStream
using the givenKeyValueMapper
to select the new key. - toStream(Named) - Method in interface org.apache.kafka.streams.kstream.KTable
-
Convert this changelog stream to a
KStream
. - 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.FixedKeyRecord
- toString() - Method in class org.apache.kafka.streams.processor.api.Record
- toString() - Method in class org.apache.kafka.streams.processor.assignment.AssignmentConfigs
- toString() - Method in class org.apache.kafka.streams.processor.assignment.KafkaStreamsAssignment.AssignedTask
- toString() - Method in class org.apache.kafka.streams.processor.assignment.KafkaStreamsAssignment
- toString() - Method in class org.apache.kafka.streams.processor.assignment.ProcessId
- toString() - Method in class org.apache.kafka.streams.processor.TaskId
- toString() - Method in class org.apache.kafka.streams.processor.To
- toString() - Method in class org.apache.kafka.streams.query.Position
- toString() - Method in class org.apache.kafka.streams.query.PositionBound
- toString() - Method in class org.apache.kafka.streams.query.StateQueryResult
- toString() - Method in class org.apache.kafka.streams.query.WindowKeyQuery
- toString() - Method in class org.apache.kafka.streams.query.WindowRangeQuery
- toString() - Method in class org.apache.kafka.streams.state.DslKeyValueParams
- toString() - Method in class org.apache.kafka.streams.state.DslSessionParams
- toString() - Method in class org.apache.kafka.streams.state.DslWindowParams
- toString() - Method in class org.apache.kafka.streams.state.HostInfo
- toString() - Method in class org.apache.kafka.streams.state.ValueAndTimestamp
- toString() - Method in class org.apache.kafka.streams.state.VersionedRecord
- 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(Materialized<K, V, KeyValueStore<Bytes, byte[]>>) - 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(Named, Materialized<K, V, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Convert this stream to a
KTable
. - toTime() - Method in class org.apache.kafka.streams.query.MultiVersionedKeyQuery
-
The ending time point of the query, if specified
- toTime(Instant) - Method in class org.apache.kafka.streams.query.MultiVersionedKeyQuery
-
Specifies the ending time point for the key query.
- transform(K, V) - Method in interface org.apache.kafka.streams.kstream.Transformer
-
Deprecated.Transform the record with the given key and value.
- transform(K, V) - Method in interface org.apache.kafka.streams.kstream.ValueTransformerWithKey
-
Transform the given [key and] value to a new value.
- transform(V) - Method in interface org.apache.kafka.streams.kstream.ValueTransformer
-
Deprecated.Transform the given value to a new value.
- Transformer<K,
V, - Interface in org.apache.kafka.streams.kstreamR> -
Deprecated.Since 4.0. Use
api.Processor
instead. - TransformerSupplier<K,
V, - Interface in org.apache.kafka.streams.kstreamR> -
Deprecated.Since 4.0. Use
api.ProcessorSupplier
instead. - 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 thisKTable
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 thisKTable
into a new value (with possibly a new type), with thekey serde
,value serde
, and the underlyingmaterialized state storage
configured in theMaterialized
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 thisKTable
into a new value (with possibly a new type), with thekey serde
,value serde
, and the underlyingmaterialized state storage
configured in theMaterialized
instance. - 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 thisKTable
into a new value (with possibly a new type), with default serializers, deserializers, and state store. - type() - Method in interface org.apache.kafka.streams.kstream.EmitStrategy
-
Returns the strategy type.
- type() - Method in class org.apache.kafka.streams.processor.assignment.KafkaStreamsAssignment.AssignedTask
U
- unavailable() - Static method in class org.apache.kafka.streams.state.HostInfo
- unbounded() - Static method in interface org.apache.kafka.streams.kstream.Suppressed.BufferConfig
-
Create a buffer unconstrained by size (either keys or bytes).
- unbounded() - Static method in class org.apache.kafka.streams.query.PositionBound
-
Creates a new PositionBound representing "no bound"
- UNKNOWN_PROCESS_ID - Enum constant in enum class org.apache.kafka.streams.processor.assignment.TaskAssignor.AssignmentError
- UNKNOWN_QUERY_TYPE - Enum constant in enum class org.apache.kafka.streams.query.FailureReason
-
Failure indicating that the store doesn't know how to handle the given query.
- UNKNOWN_TASK_ID - Enum constant in enum class org.apache.kafka.streams.processor.assignment.TaskAssignor.AssignmentError
- UnknownStateStoreException - Exception Class in org.apache.kafka.streams.errors
-
Indicates that the state store being queried is unknown, i.e., the state store does either not exist in your topology or it is not queryable.
- UnknownStateStoreException(String) - Constructor for exception class org.apache.kafka.streams.errors.UnknownStateStoreException
- UnknownStateStoreException(String, Throwable) - Constructor for exception class org.apache.kafka.streams.errors.UnknownStateStoreException
- UnknownTopologyException - Exception Class in org.apache.kafka.streams.errors
-
Indicates that the
NamedTopology
being looked up does not exist in this application - UnknownTopologyException(String, String) - Constructor for exception class org.apache.kafka.streams.errors.UnknownTopologyException
- UnknownTopologyException(String, Throwable, String) - Constructor for exception class org.apache.kafka.streams.errors.UnknownTopologyException
- UnlimitedWindows - Class in org.apache.kafka.streams.kstream
-
The unlimited window specifications used for aggregations.
- untilTimeLimit(Duration, Suppressed.BufferConfig<?>) - Static method in interface org.apache.kafka.streams.kstream.Suppressed
-
Configure the suppression to wait
timeToWaitForMoreEvents
amount of time after receiving a record before emitting it further downstream. - untilWindowCloses(Suppressed.StrictBufferConfig) - Static method in interface org.apache.kafka.streams.kstream.Suppressed
-
Configure the suppression to emit only the "final results" from the window.
- UPGRADE_FROM_0100 - Static variable in class org.apache.kafka.streams.StreamsConfig
-
Config value for parameter
"upgrade.from"
for upgrading an application from version0.10.0.x
. - UPGRADE_FROM_0101 - Static variable in class org.apache.kafka.streams.StreamsConfig
-
Config value for parameter
"upgrade.from"
for upgrading an application from version0.10.1.x
. - UPGRADE_FROM_0102 - Static variable in class org.apache.kafka.streams.StreamsConfig
-
Config value for parameter
"upgrade.from"
for upgrading an application from version0.10.2.x
. - UPGRADE_FROM_0110 - Static variable in class org.apache.kafka.streams.StreamsConfig
-
Config value for parameter
"upgrade.from"
for upgrading an application from version0.11.0.x
. - UPGRADE_FROM_10 - Static variable in class org.apache.kafka.streams.StreamsConfig
-
Config value for parameter
"upgrade.from"
for upgrading an application from version1.0.x
. - UPGRADE_FROM_11 - Static variable in class org.apache.kafka.streams.StreamsConfig
-
Config value for parameter
"upgrade.from"
for upgrading an application from version1.1.x
. - UPGRADE_FROM_20 - Static variable in class org.apache.kafka.streams.StreamsConfig
-
Config value for parameter
"upgrade.from"
for upgrading an application from version2.0.x
. - UPGRADE_FROM_21 - Static variable in class org.apache.kafka.streams.StreamsConfig
-
Config value for parameter
"upgrade.from"
for upgrading an application from version2.1.x
. - UPGRADE_FROM_22 - Static variable in class org.apache.kafka.streams.StreamsConfig
-
Config value for parameter
"upgrade.from"
for upgrading an application from version2.2.x
. - UPGRADE_FROM_23 - Static variable in class org.apache.kafka.streams.StreamsConfig
-
Config value for parameter
"upgrade.from"
for upgrading an application from version2.3.x
. - UPGRADE_FROM_24 - Static variable in class org.apache.kafka.streams.StreamsConfig
-
Config value for parameter
"upgrade.from"
for upgrading an application from version2.4.x
. - UPGRADE_FROM_25 - Static variable in class org.apache.kafka.streams.StreamsConfig
-
Config value for parameter
"upgrade.from"
for upgrading an application from version2.5.x
. - UPGRADE_FROM_26 - Static variable in class org.apache.kafka.streams.StreamsConfig
-
Config value for parameter
"upgrade.from"
for upgrading an application from version2.6.x
. - UPGRADE_FROM_27 - Static variable in class org.apache.kafka.streams.StreamsConfig
-
Config value for parameter
"upgrade.from"
for upgrading an application from version2.7.x
. - UPGRADE_FROM_28 - Static variable in class org.apache.kafka.streams.StreamsConfig
-
Config value for parameter
"upgrade.from"
for upgrading an application from version2.8.x
. - UPGRADE_FROM_30 - Static variable in class org.apache.kafka.streams.StreamsConfig
-
Config value for parameter
"upgrade.from"
for upgrading an application from version3.0.x
. - UPGRADE_FROM_31 - Static variable in class org.apache.kafka.streams.StreamsConfig
-
Config value for parameter
"upgrade.from"
for upgrading an application from version3.1.x
. - UPGRADE_FROM_32 - Static variable in class org.apache.kafka.streams.StreamsConfig
-
Config value for parameter
"upgrade.from"
for upgrading an application from version3.2.x
. - UPGRADE_FROM_33 - Static variable in class org.apache.kafka.streams.StreamsConfig
-
Config value for parameter
"upgrade.from"
for upgrading an application from version3.3.x
. - UPGRADE_FROM_34 - Static variable in class org.apache.kafka.streams.StreamsConfig
-
Config value for parameter
"upgrade.from"
for upgrading an application from version3.4.x
. - UPGRADE_FROM_35 - Static variable in class org.apache.kafka.streams.StreamsConfig
-
Config value for parameter
"upgrade.from"
for upgrading an application from version3.5.x
. - UPGRADE_FROM_36 - Static variable in class org.apache.kafka.streams.StreamsConfig
-
Config value for parameter
"upgrade.from"
for upgrading an application from version3.6.x
. - UPGRADE_FROM_37 - Static variable in class org.apache.kafka.streams.StreamsConfig
-
Config value for parameter
"upgrade.from"
for upgrading an application from version3.7.x
. - UPGRADE_FROM_38 - Static variable in class org.apache.kafka.streams.StreamsConfig
-
Config value for parameter
"upgrade.from"
for upgrading an application from version3.8.x
. - UPGRADE_FROM_39 - Static variable in class org.apache.kafka.streams.StreamsConfig
-
Config value for parameter
"upgrade.from"
for upgrading an application from version3.9.x
. - UPGRADE_FROM_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
upgrade.from
- upperBound() - Method in class org.apache.kafka.streams.query.TimestampedRangeQuery
-
The upper bound of the query, if specified
- Usage examples - Search tag in interface org.apache.kafka.streams.kstream.BranchedKStream
- Section
- UsePartitionTimeOnInvalidTimestamp - Class in org.apache.kafka.streams.processor
-
Retrieves embedded metadata timestamps from Kafka messages.
- UsePartitionTimeOnInvalidTimestamp() - Constructor for class org.apache.kafka.streams.processor.UsePartitionTimeOnInvalidTimestamp
V
- validateTaskAssignment(ApplicationState, TaskAssignor.TaskAssignment) - Static method in class org.apache.kafka.streams.processor.assignment.TaskAssignmentUtils
-
Validate the passed-in
TaskAssignor.TaskAssignment
and return anTaskAssignor.AssignmentError
representing the first error detected in the assignment, orTaskAssignor.AssignmentError.NONE
if the assignment passes the verification check. - validTo() - Method in class org.apache.kafka.streams.state.VersionedRecord
- 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.FixedKeyRecord
-
The value of the record.
- 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
- value() - Method in class org.apache.kafka.streams.state.VersionedRecord
- VALUE - Enum constant in enum class org.apache.kafka.streams.errors.ProductionExceptionHandler.SerializationExceptionOrigin
-
Serialization exception occurred during serialization of the value.
- 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, - Interface in org.apache.kafka.streams.kstreamVR> -
The
ValueJoiner
interface for joining two values into a new value of arbitrary type. - ValueJoinerWithKey<K1,
V1, - Interface in org.apache.kafka.streams.kstreamV2, VR> -
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, - Interface in org.apache.kafka.streams.kstreamVR> -
The
ValueMapperWithKey
interface for mapping a value to a new value of arbitrary type. - valueOf(String) - Static method in enum class org.apache.kafka.streams.errors.DeserializationExceptionHandler.DeserializationHandlerResponse
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.kafka.streams.errors.ProcessingExceptionHandler.ProcessingHandlerResponse
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.kafka.streams.errors.ProductionExceptionHandler.ProductionExceptionHandlerResponse
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.kafka.streams.errors.ProductionExceptionHandler.SerializationExceptionOrigin
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.kafka.streams.errors.StreamsUncaughtExceptionHandler.StreamThreadExceptionResponse
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.kafka.streams.KafkaStreams.State
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.kafka.streams.kstream.EmitStrategy.StrategyType
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.kafka.streams.kstream.Materialized.StoreType
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.kafka.streams.processor.assignment.KafkaStreamsAssignment.AssignedTask.Type
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.kafka.streams.processor.assignment.TaskAssignor.AssignmentError
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.kafka.streams.processor.PunctuationType
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.kafka.streams.processor.StandbyUpdateListener.SuspendReason
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.kafka.streams.query.FailureReason
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.kafka.streams.query.ResultOrder
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.kafka.streams.Topology.AutoOffsetReset
-
Deprecated.Returns the enum constant of this class with the specified name.
- values() - Static method in enum class org.apache.kafka.streams.errors.DeserializationExceptionHandler.DeserializationHandlerResponse
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.kafka.streams.errors.ProcessingExceptionHandler.ProcessingHandlerResponse
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.kafka.streams.errors.ProductionExceptionHandler.ProductionExceptionHandlerResponse
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.kafka.streams.errors.ProductionExceptionHandler.SerializationExceptionOrigin
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.kafka.streams.errors.StreamsUncaughtExceptionHandler.StreamThreadExceptionResponse
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.kafka.streams.KafkaStreams.State
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.kafka.streams.kstream.EmitStrategy.StrategyType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.kafka.streams.kstream.Materialized.StoreType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.kafka.streams.processor.assignment.KafkaStreamsAssignment.AssignedTask.Type
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.kafka.streams.processor.assignment.TaskAssignor.AssignmentError
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.kafka.streams.processor.PunctuationType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.kafka.streams.processor.StandbyUpdateListener.SuspendReason
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.kafka.streams.query.FailureReason
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.kafka.streams.query.ResultOrder
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.kafka.streams.Topology.AutoOffsetReset
-
Deprecated.Returns an array containing the constants of this enum class, in the order they are declared.
- valueSerde() - Method in class org.apache.kafka.streams.kstream.Joined
-
Deprecated.Since 4.0 and should not be used any longer.
- valueSerde() - Method in interface org.apache.kafka.streams.processor.api.ProcessingContext
-
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.
- valueSerde(Serde<V>) - Static method in class org.apache.kafka.streams.kstream.Grouped
-
Create a
Grouped
instance with the provided valueSerde. - valueSerde(Serde<V>) - Static method in class org.apache.kafka.streams.kstream.Produced
-
Create a Produced instance with provided valueSerde.
- valueSerde(Serde<VLeft>) - Static method in class org.apache.kafka.streams.kstream.Joined
-
Create an instance of
Joined
with a valueSerde
. - valueSerializer() - Method in class org.apache.kafka.streams.state.StateSerdes
-
Return the value serializer.
- ValueTransformer<V,
VR> - Interface in org.apache.kafka.streams.kstream -
Deprecated.Since 4.0. Use
FixedKeyProcessor
instead. - ValueTransformerSupplier<V,
VR> - Interface in org.apache.kafka.streams.kstream -
Deprecated.Since 4.0. Use
FixedKeyProcessorSupplier
instead. - ValueTransformerWithKey<K,
V, - Interface in org.apache.kafka.streams.kstreamVR> -
The
ValueTransformerWithKey
interface for stateful mapping of a value to a new value (with possible new type). - ValueTransformerWithKeySupplier<K,
V, - Interface in org.apache.kafka.streams.kstreamVR> -
A
ValueTransformerWithKeySupplier
interface which can create one or moreValueTransformerWithKey
instances. - verifyTopologyOptimizationConfigs(String) - Static method in class org.apache.kafka.streams.StreamsConfig
- VersionedBytesStore - Interface in org.apache.kafka.streams.state
-
A representation of a versioned key-value store as a
KeyValueStore
of type <Bytes, byte[]>. - VersionedBytesStoreSupplier - Interface in org.apache.kafka.streams.state
-
A store supplier that can be used to create one or more versioned key-value stores, specifically,
VersionedBytesStore
instances. - VersionedKeyQuery<K,
V> - Class in org.apache.kafka.streams.query -
Interactive query for retrieving a single record from a versioned state store based on its key and timestamp.
- VersionedKeyValueStore<K,
V> - Interface in org.apache.kafka.streams.state -
A key-value store that stores multiple record versions per key, and supports timestamp-based retrieval operations to return the latest record (per key) as of a specified timestamp.
- versionedKeyValueStoreBuilder(VersionedBytesStoreSupplier, Serde<K>, Serde<V>) - Static method in class org.apache.kafka.streams.state.Stores
-
Creates a
StoreBuilder
that can be used to build aVersionedKeyValueStore
. - VersionedRecord<V> - Class in org.apache.kafka.streams.state
-
Combines a value (from a key-value record) with a timestamp, for use as the return type from
VersionedKeyValueStore.get(Object, long)
and related methods. - VersionedRecord(V, long) - Constructor for class org.apache.kafka.streams.state.VersionedRecord
-
Create a new
VersionedRecord
instance. - VersionedRecord(V, long, long) - Constructor for class org.apache.kafka.streams.state.VersionedRecord
-
Create a new
VersionedRecord
instance. - VersionedRecordIterator<V> - Interface in org.apache.kafka.streams.state
-
Iterator interface of
VersionedRecord
.
W
- WALL_CLOCK_TIME - Enum constant in enum class org.apache.kafka.streams.processor.PunctuationType
- WallclockTimestampExtractor - Class in org.apache.kafka.streams.processor
-
Retrieves current wall clock timestamps as
System.currentTimeMillis()
. - WallclockTimestampExtractor() - Constructor for class org.apache.kafka.streams.processor.WallclockTimestampExtractor
- window() - Method in class org.apache.kafka.streams.kstream.Windowed
-
Return the window containing the values associated with this key.
- 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_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
-
A store supplier that can be used to create one or more
WindowStore<Byte, byte[]>
instances of type <Byte, byte[]>. - 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
-
windowed.inner.class.serde
- windowedBy(SessionWindows) - Method in interface org.apache.kafka.streams.kstream.CogroupedKStream
-
Create a new
SessionWindowedCogroupedKStream
instance that can be used to perform session windowed aggregations. - windowedBy(SessionWindows) - Method in interface org.apache.kafka.streams.kstream.KGroupedStream
-
Create a new
SessionWindowedKStream
instance that can be used to perform session windowed aggregations. - windowedBy(SlidingWindows) - Method in interface org.apache.kafka.streams.kstream.CogroupedKStream
-
Create a new
TimeWindowedCogroupedKStream
instance that can be used to perform sliding windowed aggregations. - 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(Windows<W>) - Method in interface org.apache.kafka.streams.kstream.CogroupedKStream
-
Create a new
TimeWindowedCogroupedKStream
instance that can be used to perform windowed aggregations. - windowedBy(Windows<W>) - Method in interface org.apache.kafka.streams.kstream.KGroupedStream
-
Create a new
TimeWindowedKStream
instance that can be used to perform windowed aggregations. - 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
- WindowKeyQuery<K,
V> - Class in org.apache.kafka.streams.query - WindowRangeQuery<K,
V> - Class in org.apache.kafka.streams.query - Windows<W> - Class in org.apache.kafka.streams.kstream
-
The window specification for fixed size windows that is used to define window boundaries and grace period.
- 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 class org.apache.kafka.streams.state.DslWindowParams
- 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
-
A
QueryableStoreType
that acceptsReadOnlyWindowStore
. - windowStore(DslWindowParams) - Method in enum class org.apache.kafka.streams.kstream.Materialized.StoreType
- windowStore(DslWindowParams) - Method in class org.apache.kafka.streams.state.BuiltInDslStoreSuppliers.InMemoryDslStoreSuppliers
- windowStore(DslWindowParams) - Method in class org.apache.kafka.streams.state.BuiltInDslStoreSuppliers.RocksDBDslStoreSuppliers
- windowStore(DslWindowParams) - Method in interface org.apache.kafka.streams.state.DslStoreSuppliers
- 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
-
Creates a
StoreBuilder
that can be used to build aWindowStore
. - WindowStoreIterator<V> - Interface in org.apache.kafka.streams.state
-
Iterator interface of
KeyValue
with key typedLong
used forWindowStore.fetch(Object, long, long)
andWindowStore.fetch(Object, Instant, Instant)
Users must call itsclose
method explicitly upon completeness to release resources, or use try-with-resources statement (available since JDK7) for thisCloseable
class. - 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.Consumed
-
Create an instance of
Consumed
with key and valueSerde
s. - 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>) - Static method in class org.apache.kafka.streams.kstream.Materialized
-
Materialize a
StateStore
with the provided key and valueSerde
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>) - Static method in class org.apache.kafka.streams.kstream.Repartitioned
-
Create a
Repartitioned
instance with provided key serde and value serde. - 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>, TimestampExtractor, 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>, TimestampExtractor, Topology.AutoOffsetReset) - Static method in class org.apache.kafka.streams.kstream.Consumed
-
Deprecated.Since 4.0. Use
Consumed.with(Serde, Serde, TimestampExtractor, AutoOffsetReset)
instead. - 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(Serde<K>, Serde<VLeft>, Serde<VRight>) - Static method in class org.apache.kafka.streams.kstream.Joined
-
Create an instance of
Joined
with key, value, and otherValueSerde
instances. - with(Serde<K>, Serde<VLeft>, Serde<VRight>, String) - Static method in class org.apache.kafka.streams.kstream.Joined
-
Create an instance of
Joined
with key, value, and otherValueSerde
instances. - with(Serde<K>, Serde<VLeft>, Serde<VRight>, String, Duration) - Static method in class org.apache.kafka.streams.kstream.Joined
-
Create an instance of
Joined
with key, value, and otherValueSerde
instances. - with(AutoOffsetReset) - Static method in class org.apache.kafka.streams.kstream.Consumed
-
Create an instance of
Consumed
with aTopology.AutoOffsetReset
. - 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 otherPartitionerStreamPartitioner
instances. - with(TimestampExtractor) - Static method in class org.apache.kafka.streams.kstream.Consumed
-
Create an instance of
Consumed
with aTimestampExtractor
. - with(DslStoreSuppliers) - Static method in class org.apache.kafka.streams.kstream.StreamJoined
-
Creates a StreamJoined instance with the given
DslStoreSuppliers
. - with(WindowBytesStoreSupplier, WindowBytesStoreSupplier) - Static method in class org.apache.kafka.streams.kstream.StreamJoined
-
Creates a StreamJoined instance with the provided store suppliers.
- with(Topology.AutoOffsetReset) - Static method in class org.apache.kafka.streams.kstream.Consumed
-
Deprecated.Since 4.0. Use
Consumed.with(AutoOffsetReset)
instead. - withAllPartitions() - Method in class org.apache.kafka.streams.query.StateQueryRequest
-
Specifies that the query will run against all locally available partitions.
- withAscendingKeys() - Method in class org.apache.kafka.streams.query.RangeQuery
-
Set the query to return the serialized byte[] of the keys in ascending order.
- withAscendingKeys() - Method in class org.apache.kafka.streams.query.TimestampedRangeQuery
-
Set the query to return the serialized byte[] of the keys in ascending order.
- withAscendingTimestamps() - Method in class org.apache.kafka.streams.query.MultiVersionedKeyQuery
-
Specifies the order of the returned records by the query as ascending by timestamp.
- 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
-
Disable caching for the materialized
StateStore
. - 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
-
Enable caching for the materialized
StateStore
. - withCachingEnabled() - Method in interface org.apache.kafka.streams.state.StoreBuilder
-
Enable caching on the store.
- withComponent(String, int, long) - Method in class org.apache.kafka.streams.query.Position
-
Augment an existing Position by setting a new offset for a topic and partition.
- 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. - withConsumer(Consumer<KStream<K, V>>) - Static method in class org.apache.kafka.streams.kstream.Branched
-
Create an instance of
Branched
with provided chain consumer. - withDescendingKeys() - Method in class org.apache.kafka.streams.query.RangeQuery
-
Set the query to return the serialized byte[] of the keys in descending order.
- withDescendingKeys() - Method in class org.apache.kafka.streams.query.TimestampedRangeQuery
-
Set the query to return the serialized byte[] of the keys in descending order.
- withDescendingTimestamps() - Method in class org.apache.kafka.streams.query.MultiVersionedKeyQuery
-
Specifies the order of the returned records by the query as descending by timestamp.
- withDslStoreSuppliers(DslStoreSuppliers) - Method in class org.apache.kafka.streams.kstream.StreamJoined
-
Configure with the provided
DslStoreSuppliers
for store suppliers that are not provided. - withFollowupRebalance(Instant) - Method in class org.apache.kafka.streams.processor.assignment.KafkaStreamsAssignment
-
This API can be used to request that a followup rebalance be triggered by the KafkaStreams client receiving this assignment.
- 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. - withGracePeriod(Duration) - Method in class org.apache.kafka.streams.kstream.Joined
-
Set the grace period on the stream side of the join.
- withHeaders(Headers) - Method in class org.apache.kafka.streams.processor.api.FixedKeyRecord
-
A convenient way to produce a new record if you only need to change the headers.
- 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(K) - Static method in class org.apache.kafka.streams.query.KeyQuery
-
Creates a query that will retrieve the record identified by
key
if it exists (ornull
otherwise). - withKey(K) - Static method in class org.apache.kafka.streams.query.MultiVersionedKeyQuery
-
Creates a query that will retrieve the set of records identified by
key
if any exists (ornull
otherwise). - withKey(K) - Static method in class org.apache.kafka.streams.query.TimestampedKeyQuery
-
Creates a query that will retrieve the record identified by
key
if it exists (ornull
otherwise). - withKey(K) - Static method in class org.apache.kafka.streams.query.VersionedKeyQuery
-
Creates a query that will retrieve the record from a versioned state store identified by
key
if it exists (ornull
otherwise). - withKey(K) - Static method in class org.apache.kafka.streams.query.WindowRangeQuery
- 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.
- withKeyAndWindowStartRange(K, Instant, Instant) - Static method in class org.apache.kafka.streams.query.WindowKeyQuery
- withKeySerde(Serde<K>) - Method in class org.apache.kafka.streams.kstream.Consumed
-
Configure the instance of
Consumed
with a keySerde
. - 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 materialized
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 providedKeyValueMapper
The provided KeyValueMapper's mapped value type must beString
. - 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
-
Disable the changelog for store built by this
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.
- withLowerBound(K) - Static method in class org.apache.kafka.streams.query.RangeQuery
-
Interactive range query using a lower bound to filter the keys returned.
- withLowerBound(K) - Static method in class org.apache.kafka.streams.query.TimestampedRangeQuery
-
Interactive range query using a lower bound to filter the keys returned.
- 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).
- withNoBounds() - Static method in class org.apache.kafka.streams.query.RangeQuery
-
Interactive scan query that returns all records in the store.
- withNoBounds() - Static method in class org.apache.kafka.streams.query.TimestampedRangeQuery
-
Interactive scan query that returns all records in the store.
- withNonOverlapCostOverride(int) - Method in class org.apache.kafka.streams.processor.assignment.TaskAssignmentUtils.RackAwareOptimizationParams
-
Return a new config object with the provided nonOverlapCost override applied
- 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(AutoOffsetReset) - Method in class org.apache.kafka.streams.kstream.Consumed
-
Configure the instance of
Consumed
with aTopology.AutoOffsetReset
. - withOffsetResetPolicy(Topology.AutoOffsetReset) - Method in class org.apache.kafka.streams.kstream.Consumed
-
Deprecated.Since 4.0. Use
Consumed.withOffsetResetPolicy(AutoOffsetReset)
instead. - withOtherPartitioner(StreamPartitioner<KO, Void>) - Method in class org.apache.kafka.streams.kstream.TableJoined
-
Set the custom other
StreamPartitioner
to be used as part of computing the join. - withOtherStoreSupplier(WindowBytesStoreSupplier) - Method in class org.apache.kafka.streams.kstream.StreamJoined
-
Configure with the provided
WindowBytesStoreSupplier
for the other store supplier. - withOtherValueSerde(Serde<V2>) - Method in class org.apache.kafka.streams.kstream.StreamJoined
-
Configure with the provided
Serde
for the other value - withOtherValueSerde(Serde<VRight>) - Method in class org.apache.kafka.streams.kstream.Joined
-
Set the otherValue
Serde
to be used. - 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
-
Set the custom
StreamPartitioner
to be used as part of computing the join. - withPartitions(Set<Integer>) - Method in class org.apache.kafka.streams.query.StateQueryRequest
-
Specifies a set of partitions to run against.
- withPositionBound(PositionBound) - Method in class org.apache.kafka.streams.query.StateQueryRequest
-
Bounds the position of the state store against its input topics.
- withQuery(Query<R>) - Method in class org.apache.kafka.streams.query.StateQueryRequest.InStore
-
Specifies the query to run on the specified store.
- withRange(K, K) - Static method in class org.apache.kafka.streams.query.RangeQuery
-
Interactive range query using a lower and upper bound to filter the keys returned.
- withRange(K, K) - Static method in class org.apache.kafka.streams.query.TimestampedRangeQuery
-
Interactive range query using a lower and upper bound to filter the keys returned.
- 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.
- withStoreType(DslStoreSuppliers) - Method in class org.apache.kafka.streams.kstream.Materialized
-
Set the type of the materialized
StateStore
. - 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
-
Configure with the provided
WindowBytesStoreSupplier
for this store supplier. - withTimestamp(long) - Method in class org.apache.kafka.streams.processor.api.FixedKeyRecord
-
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.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
-
Configure the instance of
Consumed
with aTimestampExtractor
. - withTrafficCostOverride(int) - Method in class org.apache.kafka.streams.processor.assignment.TaskAssignmentUtils.RackAwareOptimizationParams
-
Return a new config object with the provided trafficCost override applied
- withUpperBound(K) - Static method in class org.apache.kafka.streams.query.RangeQuery
-
Interactive range query using an upper bound to filter the keys returned.
- withUpperBound(K) - Static method in class org.apache.kafka.streams.query.TimestampedRangeQuery
-
Interactive range query using an upper bound to filter the keys returned.
- withValue(NewV) - Method in class org.apache.kafka.streams.processor.api.FixedKeyRecord
-
A convenient way to produce a new record if you only need to change the value.
- 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 valueSerde
. - 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.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 - withValueSerde(Serde<VLeft>) - Method in class org.apache.kafka.streams.kstream.Joined
-
Set the value
Serde
to be used. - withWindowStartRange(Instant, Instant) - Static method in class org.apache.kafka.streams.query.WindowRangeQuery
- wrapFixedKeyProcessorSupplier(String, FixedKeyProcessorSupplier<KIn, VIn, VOut>) - Method in interface org.apache.kafka.streams.processor.api.ProcessorWrapper
-
Wrap or replace the provided
FixedKeyProcessorSupplier
and return aWrappedFixedKeyProcessorSupplier
To convert aFixedKeyProcessorSupplier
instance into aWrappedFixedKeyProcessorSupplier
, use theProcessorWrapper.asWrappedFixedKey(FixedKeyProcessorSupplier)
method - WrappedFixedKeyProcessorSupplier<KIn,
VIn, - Interface in org.apache.kafka.streams.processor.apiVOut> -
Marker interface for classes implementing
FixedKeyProcessorSupplier
that have been wrapped via aProcessorWrapper
. - WrappedProcessorSupplier<KIn,
VIn, - Interface in org.apache.kafka.streams.processor.apiKOut, VOut> -
Marker interface for classes implementing
ProcessorSupplier
that have been wrapped via aProcessorWrapper
. - wrapProcessorSupplier(String, ProcessorSupplier<KIn, VIn, KOut, VOut>) - Method in interface org.apache.kafka.streams.processor.api.ProcessorWrapper
-
Wrap or replace the provided
ProcessorSupplier
and return aWrappedProcessorSupplier
To convert aProcessorSupplier
instance into aWrappedProcessorSupplier
, use theProcessorWrapper.asWrapped(ProcessorSupplier)
method
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
Topology.addSource(org.apache.kafka.streams.AutoOffsetReset, String, String...)
instead.