A B C D E F G H I J K L M N O P Q R S T U V W Z 

A

AbstractNotifyingBatchingRestoreCallback - Class in org.apache.kafka.streams.processor
Abstract implementation of the BatchingStateRestoreCallback used for batch restoration operations.
AbstractNotifyingBatchingRestoreCallback() - Constructor for class org.apache.kafka.streams.processor.AbstractNotifyingBatchingRestoreCallback
 
AbstractNotifyingRestoreCallback - Class in org.apache.kafka.streams.processor
Abstract implementation of the StateRestoreCallback used for batch restoration operations.
AbstractNotifyingRestoreCallback() - Constructor for class org.apache.kafka.streams.processor.AbstractNotifyingRestoreCallback
 
AbstractProcessor<K,V> - Class in org.apache.kafka.streams.processor
An abstract implementation of Processor that manages the ProcessorContext instance and provides default no-op implementations of AbstractProcessor.punctuate(long) and AbstractProcessor.close().
AbstractProcessor() - Constructor for class org.apache.kafka.streams.processor.AbstractProcessor
 
accepts(StateStore) - Method in interface org.apache.kafka.streams.state.QueryableStoreType
Called when searching for StateStores to see if they match the type expected by implementors of this interface
activeTasks() - Method in class org.apache.kafka.streams.processor.ThreadMetadata
 
addGlobalStore(StateStoreSupplier<KeyValueStore>, String, Deserializer, Deserializer, String, String, ProcessorSupplier) - Method in class org.apache.kafka.streams.processor.TopologyBuilder
Deprecated.
Adds a global StateStore to the topology.
addGlobalStore(StateStoreSupplier<KeyValueStore>, String, TimestampExtractor, Deserializer, Deserializer, String, String, ProcessorSupplier) - Method in class org.apache.kafka.streams.processor.TopologyBuilder
Deprecated.
Adds a global StateStore to the topology.
addGlobalStore(StoreBuilder, String, String, Consumed, String, ProcessorSupplier) - Method in class org.apache.kafka.streams.StreamsBuilder
addGlobalStore(StoreBuilder, String, Consumed, ProcessorSupplier) - Method in class org.apache.kafka.streams.StreamsBuilder
Adds a global StateStore to the topology.
addGlobalStore(StoreBuilder, String, Deserializer, Deserializer, String, String, ProcessorSupplier) - Method in class org.apache.kafka.streams.Topology
Adds a global StateStore to the topology.
addGlobalStore(StoreBuilder, String, TimestampExtractor, Deserializer, Deserializer, String, String, ProcessorSupplier) - Method in class org.apache.kafka.streams.Topology
Adds a global StateStore to the topology.
addInternalTopic(String) - Method in class org.apache.kafka.streams.processor.TopologyBuilder
Deprecated.
Adds an internal topic NOTE this function would not needed by developers working with the processor APIs, but only used for the high-level DSL parsing functionalities.
addLatencyAndThroughputSensor(String, String, String, Sensor.RecordingLevel, String...) - Method in interface org.apache.kafka.streams.StreamsMetrics
Add a latency and throughput sensor for a specific operation, which will include the following sensors: average latency max latency throughput (num.operations / time unit) Also create a parent sensor with the same metrics that aggregates all entities with the same operation under the same scope if it has not been created.
addProcessor(String, ProcessorSupplier, String...) - Method in class org.apache.kafka.streams.processor.TopologyBuilder
Deprecated.
Add a new processor node that receives and processes records output by one or more predecessor source or processor node.
addProcessor(String, ProcessorSupplier, String...) - Method in class org.apache.kafka.streams.Topology
Add a new processor node that receives and processes records output by one or more parent source or processor node.
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.processor.TopologyBuilder
Deprecated.
Add a new sink that forwards records from predecessor nodes (processors and/or sources) to the named Kafka topic.
addSink(String, String, StreamPartitioner, String...) - Method in class org.apache.kafka.streams.processor.TopologyBuilder
Deprecated.
Add a new sink that forwards records from predecessor nodes (processors and/or sources) to the named Kafka topic, using the supplied partitioner.
addSink(String, String, Serializer, Serializer, String...) - Method in class org.apache.kafka.streams.processor.TopologyBuilder
Deprecated.
Add a new sink that forwards records from predecessor nodes (processors and/or sources) to the named Kafka topic.
addSink(String, String, Serializer<K>, Serializer<V>, StreamPartitioner<? super K, ? super V>, String...) - Method in class org.apache.kafka.streams.processor.TopologyBuilder
Deprecated.
Add a new sink that forwards records from predecessor nodes (processors and/or sources) to the named Kafka topic.
addSink(String, String, String...) - Method in class org.apache.kafka.streams.Topology
Add a new sink that forwards records from upstream parent processor and/or source nodes to the named Kafka topic.
addSink(String, String, StreamPartitioner<? super K, ? super V>, String...) - Method in class org.apache.kafka.streams.Topology
Add a new sink that forwards records from upstream parent processor and/or source nodes to the named Kafka topic, using the supplied partitioner.
addSink(String, String, Serializer<K>, Serializer<V>, String...) - Method in class org.apache.kafka.streams.Topology
Add a new sink that forwards records from upstream parent processor and/or source nodes to the named Kafka topic.
addSink(String, String, Serializer<K>, Serializer<V>, StreamPartitioner<? super K, ? super V>, String...) - Method in class org.apache.kafka.streams.Topology
Add a new sink that forwards records from upstream parent processor and/or source nodes to the named Kafka topic.
addSource(String, String...) - Method in class org.apache.kafka.streams.processor.TopologyBuilder
Deprecated.
Add a new source that consumes the named topics and forward the records to child processor and/or sink nodes.
addSource(TopologyBuilder.AutoOffsetReset, String, String...) - Method in class org.apache.kafka.streams.processor.TopologyBuilder
Deprecated.
Add a new source that consumes the named topics and forward the records to child processor and/or sink nodes.
addSource(TimestampExtractor, String, String...) - Method in class org.apache.kafka.streams.processor.TopologyBuilder
Deprecated.
Add a new source that consumes the named topics and forward the records to child processor and/or sink nodes.
addSource(TopologyBuilder.AutoOffsetReset, TimestampExtractor, String, String...) - Method in class org.apache.kafka.streams.processor.TopologyBuilder
Deprecated.
Add a new source that consumes the named topics and forward the records to child processor and/or sink nodes.
addSource(String, Pattern) - Method in class org.apache.kafka.streams.processor.TopologyBuilder
Deprecated.
Add a new source that consumes from topics matching the given pattern and forward the records to child processor and/or sink nodes.
addSource(TopologyBuilder.AutoOffsetReset, String, Pattern) - Method in class org.apache.kafka.streams.processor.TopologyBuilder
Deprecated.
Add a new source that consumes from topics matching the given pattern and forward the records to child processor and/or sink nodes.
addSource(TimestampExtractor, String, Pattern) - Method in class org.apache.kafka.streams.processor.TopologyBuilder
Deprecated.
Add a new source that consumes from topics matching the given pattern and forward the records to child processor and/or sink nodes.
addSource(TopologyBuilder.AutoOffsetReset, TimestampExtractor, String, Pattern) - Method in class org.apache.kafka.streams.processor.TopologyBuilder
Deprecated.
Add a new source that consumes from topics matching the given pattern and forward the records to child processor and/or sink nodes.
addSource(String, Deserializer, Deserializer, String...) - Method in class org.apache.kafka.streams.processor.TopologyBuilder
Deprecated.
Add a new source that consumes the named topics and forwards the records to child processor and/or sink nodes.
addSource(TopologyBuilder.AutoOffsetReset, String, TimestampExtractor, Deserializer, Deserializer, String...) - Method in class org.apache.kafka.streams.processor.TopologyBuilder
Deprecated.
Add a new source that consumes the named topics and forwards the records to child processor and/or sink nodes.
addSource(String, Deserializer, Deserializer, Pattern) - Method in class org.apache.kafka.streams.processor.TopologyBuilder
Deprecated.
Add a new source that consumes from topics matching the given pattern and forwards the records to child processor and/or sink nodes.
addSource(TopologyBuilder.AutoOffsetReset, String, TimestampExtractor, Deserializer, Deserializer, Pattern) - Method in class org.apache.kafka.streams.processor.TopologyBuilder
Deprecated.
Add a new source that consumes from topics matching the given pattern and forwards the records to child processor and/or sink nodes.
addSource(TopologyBuilder.AutoOffsetReset, String, Deserializer, Deserializer, Pattern) - Method in class org.apache.kafka.streams.processor.TopologyBuilder
Deprecated.
Add a new source that consumes from topics matching the given pattern and forwards the records to child processor and/or sink nodes.
addSource(String, String...) - Method in class org.apache.kafka.streams.Topology
Add a new source that consumes the named topics and forward the records to child processor and/or sink nodes.
addSource(String, Pattern) - Method in class org.apache.kafka.streams.Topology
Add a new source that consumes from topics matching the given pattern and forward the records to child processor and/or sink nodes.
addSource(Topology.AutoOffsetReset, String, String...) - Method in class org.apache.kafka.streams.Topology
Add a new source that consumes the named topics and forward the records to child processor and/or sink nodes.
addSource(Topology.AutoOffsetReset, String, Pattern) - Method in class org.apache.kafka.streams.Topology
Add a new source that consumes from topics matching the given pattern and forward the records to child processor and/or sink nodes.
addSource(TimestampExtractor, String, String...) - Method in class org.apache.kafka.streams.Topology
Add a new source that consumes the named topics and forward the records to child processor and/or sink nodes.
addSource(TimestampExtractor, String, Pattern) - Method in class org.apache.kafka.streams.Topology
Add a new source that consumes from topics matching the given pattern and forward the records to child processor and/or sink nodes.
addSource(Topology.AutoOffsetReset, TimestampExtractor, String, String...) - Method in class org.apache.kafka.streams.Topology
Add a new source that consumes the named topics and forward the records to child processor and/or sink nodes.
addSource(Topology.AutoOffsetReset, TimestampExtractor, String, Pattern) - Method in class org.apache.kafka.streams.Topology
Add a new source that consumes from topics matching the given pattern and forward the records to child processor and/or sink nodes.
addSource(String, Deserializer, Deserializer, String...) - Method in class org.apache.kafka.streams.Topology
Add a new source that consumes the named topics and forwards the records to child processor and/or sink nodes.
addSource(String, Deserializer, Deserializer, Pattern) - Method in class org.apache.kafka.streams.Topology
Add a new source that consumes from topics matching the given pattern and forwards the records to child processor and/or sink nodes.
addSource(Topology.AutoOffsetReset, String, Deserializer, Deserializer, String...) - Method in class org.apache.kafka.streams.Topology
Add a new source that consumes from topics matching the given pattern and forwards the records to child processor and/or sink nodes.
addSource(Topology.AutoOffsetReset, String, Deserializer, Deserializer, Pattern) - Method in class org.apache.kafka.streams.Topology
Add a new source that consumes from topics matching the given pattern and forwards the records to child processor and/or sink nodes.
addSource(Topology.AutoOffsetReset, String, TimestampExtractor, Deserializer, Deserializer, String...) - Method in class org.apache.kafka.streams.Topology
Add a new source that consumes the named topics and forwards the records to child processor and/or sink nodes.
addSource(Topology.AutoOffsetReset, String, TimestampExtractor, Deserializer, Deserializer, Pattern) - Method in class org.apache.kafka.streams.Topology
Add a new source that consumes from topics matching the given pattern and forwards the records to child processor and/or sink nodes.
addStateStore(StateStoreSupplier, String...) - Method in class org.apache.kafka.streams.processor.TopologyBuilder
Deprecated.
Adds a state store
addStateStore(StoreBuilder) - Method in class org.apache.kafka.streams.StreamsBuilder
Adds a state store to the underlying Topology.
addStateStore(StoreBuilder, String...) - Method in class org.apache.kafka.streams.Topology
Adds a state store.
addThroughputSensor(String, String, String, Sensor.RecordingLevel, String...) - Method in interface org.apache.kafka.streams.StreamsMetrics
Add a throughput sensor for a specific operation: throughput (num.operations / time unit) Also create a parent sensor with the same metrics that aggregates all entities with the same operation under the same scope if it has not been created.
ADMIN_CLIENT_PREFIX - Static variable in class org.apache.kafka.streams.StreamsConfig
Prefix used to isolate admin configs from other client configs.
adminClientPrefix(String) - Static method in class org.apache.kafka.streams.StreamsConfig
Prefix a property with StreamsConfig.ADMIN_CLIENT_PREFIX.
advanceBy(long) - 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(long) - Method in class org.apache.kafka.streams.kstream.JoinWindows
Changes the end window boundary to timeDifferenceMs 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<VR>, Aggregator<? super K, ? super V, VR>, Serde<VR>, String) - Method in interface org.apache.kafka.streams.kstream.KGroupedStream
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>) - 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>, Serde<VR>) - Method in interface org.apache.kafka.streams.kstream.KGroupedStream
aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, StateStoreSupplier<KeyValueStore>) - Method in interface org.apache.kafka.streams.kstream.KGroupedStream
aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, Windows<W>, Serde<VR>, String) - Method in interface org.apache.kafka.streams.kstream.KGroupedStream
aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, Windows<W>, Serde<VR>) - Method in interface org.apache.kafka.streams.kstream.KGroupedStream
Deprecated.
use windowedBy(windows) followed by TimeWindowedKStream.aggregate(Initializer, Aggregator, Materialized) aggregate(initializer, aggregator, Materialized.with(null, aggValueSerde))}
aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, Windows<W>, StateStoreSupplier<WindowStore>) - Method in interface org.apache.kafka.streams.kstream.KGroupedStream
aggregate(Initializer<T>, Aggregator<? super K, ? super V, T>, Merger<? super K, T>, SessionWindows, Serde<T>, String) - Method in interface org.apache.kafka.streams.kstream.KGroupedStream
aggregate(Initializer<T>, Aggregator<? super K, ? super V, T>, Merger<? super K, T>, SessionWindows, Serde<T>) - Method in interface org.apache.kafka.streams.kstream.KGroupedStream
aggregate(Initializer<T>, Aggregator<? super K, ? super V, T>, Merger<? super K, T>, SessionWindows, Serde<T>, StateStoreSupplier<SessionStore>) - Method in interface org.apache.kafka.streams.kstream.KGroupedStream
aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, Aggregator<? super K, ? super V, VR>, String) - 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 the value of records of the original KTable that got mapped to the same key into a new instance of KTable using default serializers and deserializers.
aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, Aggregator<? super K, ? super V, VR>) - Method in interface org.apache.kafka.streams.kstream.KGroupedTable
Aggregate the value of records of the original KTable that got mapped to the same key into a new instance of KTable using default serializers and deserializers.
aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, Aggregator<? super K, ? super V, VR>, Serde<VR>, String) - Method in interface org.apache.kafka.streams.kstream.KGroupedTable
aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, Aggregator<? super K, ? super V, VR>, Serde<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>, StateStoreSupplier<KeyValueStore>) - Method in interface org.apache.kafka.streams.kstream.KGroupedTable
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 SessionWindows.
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 SessionWindows.
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.
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.
Aggregator<K,V,VA> - Interface in org.apache.kafka.streams.kstream
The Aggregator interface for aggregating values of the given key.
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.
allMetadata() - Method in class org.apache.kafka.streams.KafkaStreams
Find all currently running KafkaStreams instances (potentially remotely) that use the same application ID as this instance (i.e., all instances that belong to the same Kafka Streams application) and return StreamsMetadata for each discovered instance.
allMetadataForStore(String) - Method in class org.apache.kafka.streams.KafkaStreams
Find all currently running KafkaStreams instances (potentially remotely) that use the same application ID as this instance (i.e., all instances that belong to the same Kafka Streams application) and that contain a StateStore with the given storeName and return StreamsMetadata for each discovered instance.
appConfigs() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
Returns all the application config properties as key/value pairs.
appConfigsWithPrefix(String) - Method in interface org.apache.kafka.streams.processor.ProcessorContext
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
user.endpoint
applicationId() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
Returns the application id
apply(K, V, VA) - Method in interface org.apache.kafka.streams.kstream.Aggregator
Compute a new aggregate from the key and value of a record and the current aggregate of the same key.
apply(K, V) - Method in interface org.apache.kafka.streams.kstream.ForeachAction
Perform an action for each record of a stream.
apply() - Method in interface org.apache.kafka.streams.kstream.Initializer
Return the initial value for an aggregation.
apply(K, V) - Method in interface org.apache.kafka.streams.kstream.KeyValueMapper
Map a record with the given key and value to a new value.
apply(K, V, V) - Method in interface org.apache.kafka.streams.kstream.Merger
Compute a new aggregate from the key and two aggregates.
apply(V, V) - Method in interface org.apache.kafka.streams.kstream.Reducer
Aggregate the two given values into a single one.
apply(V1, V2) - Method in interface org.apache.kafka.streams.kstream.ValueJoiner
Return a joined value consisting of value1 and value2.
apply(V) - Method in interface org.apache.kafka.streams.kstream.ValueMapper
Map the given value to a new value.
apply(K, V) - Method in interface org.apache.kafka.streams.kstream.ValueMapperWithKey
Map the given [key and ]value to a new value.
approximateNumEntries() - Method in interface org.apache.kafka.streams.state.ReadOnlyKeyValueStore
Return an approximate count of key-value mappings in this store.
as(String) - Static method in class org.apache.kafka.streams.kstream.Materialized
Materialize a StateStore with the given name.
as(WindowBytesStoreSupplier) - Static method in class org.apache.kafka.streams.kstream.Materialized
Materialize a WindowStore using the provided WindowBytesStoreSupplier.
as(SessionBytesStoreSupplier) - Static method in class org.apache.kafka.streams.kstream.Materialized
Materialize a SessionStore using the provided SessionBytesStoreSupplier.
as(KeyValueBytesStoreSupplier) - Static method in class org.apache.kafka.streams.kstream.Materialized
Materialize a KeyValueStore using the provided KeyValueBytesStoreSupplier.
AT_LEAST_ONCE - Static variable in class org.apache.kafka.streams.StreamsConfig
Config value for parameter "processing.guarantee" for at-least-once processing guarantees.

B

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 the StateRestoreCallback.restore(byte[], byte[]) method.
before(long) - Method in class org.apache.kafka.streams.kstream.JoinWindows
Changes the start window boundary to timeDifferenceMs 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.
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.KStream
Creates an array of KStream from this stream by branching the records in the original stream based on the supplied predicates.
BrokerNotFoundException - Exception in org.apache.kafka.streams.errors
Indicates that none of the specified brokers could be found.
BrokerNotFoundException(String) - Constructor for exception org.apache.kafka.streams.errors.BrokerNotFoundException
 
BrokerNotFoundException(String, Throwable) - Constructor for exception org.apache.kafka.streams.errors.BrokerNotFoundException
 
BrokerNotFoundException(Throwable) - Constructor for exception org.apache.kafka.streams.errors.BrokerNotFoundException
 
BUFFERED_RECORDS_PER_PARTITION_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
buffered.records.per.partition
build(Integer) - Method in class org.apache.kafka.streams.processor.TopologyBuilder
Deprecated.
Build the topology for the specified topic group.
build() - Method in interface org.apache.kafka.streams.state.StoreBuilder
Build the store as defined by the builder.
build() - Method in interface org.apache.kafka.streams.state.Stores.InMemoryKeyValueFactory
Deprecated.
Return the instance of StateStoreSupplier of new key-value store.
build() - Method in interface org.apache.kafka.streams.state.Stores.PersistentKeyValueFactory
Deprecated.
Return the instance of StateStoreSupplier of new key-value store.
build() - Method in class org.apache.kafka.streams.StreamsBuilder
Returns the Topology that represents the specified processing logic.
buildGlobalStateTopology() - Method in class org.apache.kafka.streams.processor.TopologyBuilder
Deprecated.
Builds the topology for any global state stores NOTE this function would not needed by developers working with the processor APIs, but only used for the high-level DSL parsing functionalities.

C

CACHE_MAX_BYTES_BUFFERING_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
cache.max.bytes.buffering
cachingEnabled - Variable in class org.apache.kafka.streams.kstream.Materialized
 
cancel() - Method in interface org.apache.kafka.streams.processor.Cancellable
Cancel the scheduled operation to avoid future calls.
Cancellable - Interface in org.apache.kafka.streams.processor
cleanUp() - Method in class org.apache.kafka.streams.KafkaStreams
Do a clean up of the local StateStore directory (StreamsConfig.STATE_DIR_CONFIG) by deleting all data with regard to the application ID.
CLIENT_ID_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
client.id
close() - Method in class org.apache.kafka.streams.KafkaStreams
Shutdown this KafkaStreams instance by signaling all the threads to stop, and then wait for them to join.
close(long, TimeUnit) - Method in class org.apache.kafka.streams.KafkaStreams
Shutdown this KafkaStreams by signaling all the threads to stop, and then wait up to the timeout for the threads to join.
close() - Method in interface org.apache.kafka.streams.kstream.Transformer
Close this processor and clean up any resources.
close() - Method in interface org.apache.kafka.streams.kstream.ValueTransformer
Close this processor and clean up any resources.
close() - Method in interface org.apache.kafka.streams.kstream.ValueTransformerWithKey
Close this processor and clean up any resources.
close() - Method in class org.apache.kafka.streams.processor.AbstractProcessor
Close this processor and clean up any resources.
close() - Method in interface org.apache.kafka.streams.processor.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.WindowStoreIterator
 
commit() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
Requests a commit
COMMIT_INTERVAL_MS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
commit.interval.ms
compareTo(TaskId) - Method in class org.apache.kafka.streams.processor.TaskId
 
configDef() - Static method in class org.apache.kafka.streams.StreamsConfig
Return a copy of the config definition.
configure(Map<String, ?>) - Method in class org.apache.kafka.streams.errors.DefaultProductionExceptionHandler
 
configure(Map<String, ?>) - Method in class org.apache.kafka.streams.errors.LogAndContinueExceptionHandler
 
configure(Map<String, ?>) - Method in class org.apache.kafka.streams.errors.LogAndFailExceptionHandler
 
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.processor.TopologyBuilder
Deprecated.
Connects the processor and the state stores
connectProcessorAndStateStores(String, String...) - Method in class org.apache.kafka.streams.Topology
Connects the processor and the state stores.
connectProcessors(String...) - Method in class org.apache.kafka.streams.processor.TopologyBuilder
Deprecated.
Connects a list of processors.
connectSourceStoreAndTopic(String, String) - Method in class org.apache.kafka.streams.processor.TopologyBuilder
Deprecated.
This is used only for KStreamBuilder: when adding a KTable from a source topic, we need to add the topic as the KTable's materialized state store's changelog.
Consumed<K,V> - Class in org.apache.kafka.streams
The Consumed class is used to define the optional parameters when using StreamsBuilder to build instances of KStream, KTable, and GlobalKTable.
Consumed(Consumed<K, V>) - Constructor for class org.apache.kafka.streams.Consumed
Create an instance of Consumed from an existing instance.
CONSUMER_PREFIX - Static variable in class org.apache.kafka.streams.StreamsConfig
Prefix used to isolate consumer configs from other client configs.
consumerPrefix(String) - Static method in class org.apache.kafka.streams.StreamsConfig
Prefix a property with StreamsConfig.CONSUMER_PREFIX.
context() - Method in class org.apache.kafka.streams.processor.AbstractProcessor
Get the processor's context set during initialization.
copartitionGroups() - Method in class org.apache.kafka.streams.processor.TopologyBuilder
Deprecated.
Returns the copartition groups.
copartitionSources(Collection<String>) - Method in class org.apache.kafka.streams.processor.TopologyBuilder
Deprecated.
Asserts that the streams of the specified source nodes must be copartitioned.
count(String) - Method in interface org.apache.kafka.streams.kstream.KGroupedStream
count() - Method in interface org.apache.kafka.streams.kstream.KGroupedStream
Count the number of records in this stream by the grouped key.
count(StateStoreSupplier<KeyValueStore>) - Method in interface org.apache.kafka.streams.kstream.KGroupedStream
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(Windows<W>, String) - Method in interface org.apache.kafka.streams.kstream.KGroupedStream
count(Windows<W>) - Method in interface org.apache.kafka.streams.kstream.KGroupedStream
Deprecated.
count(Windows<W>, StateStoreSupplier<WindowStore>) - Method in interface org.apache.kafka.streams.kstream.KGroupedStream
count(SessionWindows, String) - Method in interface org.apache.kafka.streams.kstream.KGroupedStream
count(SessionWindows) - Method in interface org.apache.kafka.streams.kstream.KGroupedStream
Deprecated.
count(SessionWindows, StateStoreSupplier<SessionStore>) - Method in interface org.apache.kafka.streams.kstream.KGroupedStream
count(String) - Method in interface org.apache.kafka.streams.kstream.KGroupedTable
count(Materialized<K, Long, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KGroupedTable
Count number of records of the original KTable that got mapped to the same key into a new instance of KTable.
count() - Method in interface org.apache.kafka.streams.kstream.KGroupedTable
Count number of records of the original KTable that got mapped to the same key into a new instance of KTable.
count(StateStoreSupplier<KeyValueStore>) - 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 into SessionWindows.
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 into SessionWindows.
count() - Method in interface org.apache.kafka.streams.kstream.TimeWindowedKStream
Count the number of records in this stream by the grouped key and the defined windows.
count(Materialized<K, Long, WindowStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.TimeWindowedKStream
Count the number of records in this stream by the grouped key and the defined windows.
create(StateStoreProvider, String) - Method in interface org.apache.kafka.streams.state.QueryableStoreType
Create an instance of T (usually a facade) that developers can use to query the underlying StateStores
create(String) - Static method in class org.apache.kafka.streams.state.Stores

D

DEFAULT_DESERIALIZATION_EXCEPTION_HANDLER_CLASS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
default.deserialization.exception.handler
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
default.production.exception.handler
DEFAULT_TIMESTAMP_EXTRACTOR_CLASS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
default timestamp.extractor
DEFAULT_VALUE_SERDE_CLASS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
default value.serde
defaultDeserializationExceptionHandler() - Method in class org.apache.kafka.streams.StreamsConfig
 
defaultKeySerde() - Method in class org.apache.kafka.streams.StreamsConfig
Return an configured instance of key Serde class.
DefaultPartitionGrouper - Class in org.apache.kafka.streams.processor
Default implementation of the PartitionGrouper interface that groups partitions by the partition id.
DefaultPartitionGrouper() - Constructor for class org.apache.kafka.streams.processor.DefaultPartitionGrouper
 
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
 
defaultProductionExceptionHandler() - Method in class org.apache.kafka.streams.StreamsConfig
 
defaultTimestampExtractor() - Method in class org.apache.kafka.streams.StreamsConfig
 
defaultValueSerde() - Method in class org.apache.kafka.streams.StreamsConfig
Return an configured instance of value Serde class.
delete(K) - Method in interface org.apache.kafka.streams.state.KeyValueStore
Delete the value from the store (if there is one)
describe() - Method in class org.apache.kafka.streams.Topology
Returns a description of the specified Topology.
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 in org.apache.kafka.streams.errors
Enumeration that describes the response from the exception handler.
disableLogging() - Method in interface org.apache.kafka.streams.state.Stores.InMemoryKeyValueFactory
Deprecated.
Indicates that a changelog should not be created for the key-value store
disableLogging() - Method in interface org.apache.kafka.streams.state.Stores.PersistentKeyValueFactory
Deprecated.
Indicates that a changelog should not be created for the key-value store

E

earliestResetTopicsPattern() - Method in class org.apache.kafka.streams.processor.TopologyBuilder
Deprecated.
Get the Pattern to match all topics requiring to start reading from earliest available offset NOTE this function would not needed by developers working with the processor APIs, but only used for the high-level DSL parsing functionalities.
enableCaching() - Method in interface org.apache.kafka.streams.state.Stores.PersistentKeyValueFactory
Deprecated.
Caching should be enabled on the created store.
enableLogging(Map<String, String>) - Method in interface org.apache.kafka.streams.state.Stores.InMemoryKeyValueFactory
Deprecated.
Indicates that a changelog should be created for the store.
enableLogging(Map<String, String>) - Method in interface org.apache.kafka.streams.state.Stores.PersistentKeyValueFactory
Deprecated.
Indicates that a changelog should be created for the store.
end() - Method in class org.apache.kafka.streams.kstream.Window
Return the end timestamp of this window.
endMs - Variable in class org.apache.kafka.streams.kstream.Window
 
equals(Object) - Method in class org.apache.kafka.streams.KeyValue
 
equals(Object) - Method in class org.apache.kafka.streams.kstream.JoinWindows
 
equals(Object) - Method in class org.apache.kafka.streams.kstream.SessionWindows
 
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.processor.TaskId
 
equals(Object) - Method in class org.apache.kafka.streams.processor.TaskMetadata
 
equals(Object) - Method in class org.apache.kafka.streams.processor.ThreadMetadata
 
equals(Object) - Method in class org.apache.kafka.streams.processor.TopologyBuilder.TopicsInfo
Deprecated.
 
equals(Object) - Method in class org.apache.kafka.streams.state.HostInfo
 
equals(Object) - Method in class org.apache.kafka.streams.state.StreamsMetadata
 
EXACTLY_ONCE - Static variable in class org.apache.kafka.streams.StreamsConfig
Config value for parameter "processing.guarantee" for exactly-once processing guarantees.
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

FailOnInvalidTimestamp - Class in org.apache.kafka.streams.processor
Retrieves embedded metadata timestamps from Kafka messages.
FailOnInvalidTimestamp() - Constructor for class org.apache.kafka.streams.processor.FailOnInvalidTimestamp
 
fetch(K) - Method in interface org.apache.kafka.streams.state.ReadOnlySessionStore
Retrieve all aggregated sessions for the provided key.
fetch(K, K) - Method in interface org.apache.kafka.streams.state.ReadOnlySessionStore
Retrieve all aggregated sessions for the given range of keys.
fetch(K, long, long) - Method in interface org.apache.kafka.streams.state.ReadOnlyWindowStore
Get all the key-value pairs with the given key and the time range from all the existing windows.
fetch(K, K, long, long) - 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.
fetchAll(long, long) - 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.
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 this KTable which satisfy the given predicate.
filter(Predicate<? super K, ? super V>, Materialized<K, V, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KTable
Create a new KTable that consists of all records of this KTable which satisfy the given predicate.
filter(Predicate<? super K, ? super V>, String) - Method in interface org.apache.kafka.streams.kstream.KTable
filter(Predicate<? super K, ? super V>, StateStoreSupplier<KeyValueStore>) - Method in interface org.apache.kafka.streams.kstream.KTable
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 this KTable which do not satisfy the given predicate.
filterNot(Predicate<? super K, ? super V>, Materialized<K, V, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KTable
Create a new KTable that consists all records of this KTable which do not satisfy the given predicate.
filterNot(Predicate<? super K, ? super V>, StateStoreSupplier<KeyValueStore>) - Method in interface org.apache.kafka.streams.kstream.KTable
filterNot(Predicate<? super K, ? super V>, String) - Method in interface org.apache.kafka.streams.kstream.KTable
findSessions(K, long, long) - Method in interface org.apache.kafka.streams.state.SessionStore
Fetch any sessions with the matching key and the sessions end is ≥ earliestSessionEndTime and the sessions start is ≤ latestSessionStartTime This iterator must be closed after use.
findSessions(K, K, long, long) - Method in interface org.apache.kafka.streams.state.SessionStore
Fetch any sessions in the given range of keys and the sessions end is ≥ earliestSessionEndTime and the sessions start is ≤ latestSessionStartTime This iterator must be closed after use.
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).
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(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.
flush() - Method in interface org.apache.kafka.streams.processor.StateStore
Flush any cached data
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>) - Method in interface org.apache.kafka.streams.kstream.KTable
Deprecated.
Use the Interactive Queries APIs (e.g., KafkaStreams.store(String, QueryableStoreType) followed by ReadOnlyKeyValueStore.all()) to iterate over the keys of a KTable. Alternatively convert to a KStream using KTable.toStream() and then use foreach(action) on the result.
ForeachAction<K,V> - Interface in org.apache.kafka.streams.kstream
The ForeachAction interface for performing an action on a key-value pair.
forward(K, V) - Method in interface org.apache.kafka.streams.processor.ProcessorContext
Forwards a key/value pair to the downstream processors
forward(K, V, int) - Method in interface org.apache.kafka.streams.processor.ProcessorContext
Forwards a key/value pair to one of the downstream processors designated by childIndex
forward(K, V, String) - Method in interface org.apache.kafka.streams.processor.ProcessorContext
Forwards a key/value pair to one of the downstream processors designated by the downstream processor name

G

get() - Method in interface org.apache.kafka.streams.kstream.TransformerSupplier
Return a new Transformer instance.
get() - Method in interface org.apache.kafka.streams.kstream.ValueTransformerSupplier
Return a new ValueTransformer instance.
get() - Method in interface org.apache.kafka.streams.kstream.ValueTransformerWithKeySupplier
 
get() - Method in interface org.apache.kafka.streams.processor.ProcessorSupplier
Return a new Processor instance.
get() - Method in interface org.apache.kafka.streams.processor.StateStoreSupplier
Deprecated.
Return a new StateStore instance.
get(K) - Method in interface org.apache.kafka.streams.state.ReadOnlyKeyValueStore
Get the value corresponding to this key.
get() - Method in interface org.apache.kafka.streams.state.StoreSupplier
Return a new StateStore instance.
getAdminClient(Map<String, Object>) - Method in interface org.apache.kafka.streams.KafkaClientSupplier
Create an AdminClient which is used for internal topic management.
getAdminConfigs(String) - Method in class org.apache.kafka.streams.StreamsConfig
Get the configs for the admin client.
getConsumer(Map<String, Object>) - Method in interface org.apache.kafka.streams.KafkaClientSupplier
Create a Consumer which is used to read records of source topics.
getConsumerConfigs(String, String) - Method in class org.apache.kafka.streams.StreamsConfig
Get the configs to the consumer.
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.
getRestoreConsumer(Map<String, Object>) - Method in interface org.apache.kafka.streams.KafkaClientSupplier
Create a Consumer which is used to read records to restore StateStores.
getRestoreConsumerConfigs(String) - Method in class org.apache.kafka.streams.StreamsConfig
Get the configs for the restore-consumer.
getStateStore(String) - Method in interface org.apache.kafka.streams.processor.ProcessorContext
Get the state store given the store name.
GlobalKTable<K,V> - Interface in org.apache.kafka.streams.kstream
GlobalKTable is an abstraction of a changelog stream from a primary-keyed table.
globalStateStores() - Method in class org.apache.kafka.streams.processor.TopologyBuilder
Deprecated.
Get any global StateStores that are part of the topology NOTE this function would not needed by developers working with the processor APIs, but only used for the high-level DSL parsing functionalities.
globalStores() - Method in interface org.apache.kafka.streams.TopologyDescription
All global stores of the represented topology.
globalTable(String, String) - Method in class org.apache.kafka.streams.kstream.KStreamBuilder
Deprecated.
Create a GlobalKTable for the specified topic.
globalTable(String) - Method in class org.apache.kafka.streams.kstream.KStreamBuilder
Deprecated.
Create a GlobalKTable for the specified topic.
globalTable(Serde<K>, Serde<V>, TimestampExtractor, String, String) - Method in class org.apache.kafka.streams.kstream.KStreamBuilder
Deprecated.
Create a GlobalKTable for the specified topic.
globalTable(Serde<K>, Serde<V>, String, StateStoreSupplier<KeyValueStore>) - Method in class org.apache.kafka.streams.kstream.KStreamBuilder
Deprecated.
Create a GlobalKTable for the specified topic.
globalTable(Serde<K>, Serde<V>, String, String) - Method in class org.apache.kafka.streams.kstream.KStreamBuilder
Deprecated.
Create a GlobalKTable for the specified topic.
globalTable(Serde<K>, Serde<V>, String) - Method in class org.apache.kafka.streams.kstream.KStreamBuilder
Deprecated.
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) - 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.
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 provided KeyValueMapper and default serializers and deserializers.
groupBy(KeyValueMapper<? super K, ? super V, KR>, Serialized<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 provided KeyValueMapper and Serdes as specified by Serialized.
groupBy(KeyValueMapper<? super K, ? super V, KR>, Serde<KR>, Serde<V>) - Method in interface org.apache.kafka.streams.kstream.KStream
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 provided KeyValueMapper and default serializers and deserializers.
groupBy(KeyValueMapper<? super K, ? super V, KeyValue<KR, VR>>, Serialized<KR, VR>) - Method in interface org.apache.kafka.streams.kstream.KTable
Re-groups the records of this KTable using the provided KeyValueMapper and Serdes as specified by Serialized.
groupBy(KeyValueMapper<? super K, ? super V, KeyValue<KR, VR>>, Serde<KR>, Serde<VR>) - Method in interface org.apache.kafka.streams.kstream.KTable
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(Serialized<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 by Serialized.
groupByKey(Serde<K>, Serde<V>) - Method in interface org.apache.kafka.streams.kstream.KStream

H

handle(ProducerRecord<byte[], byte[]>, Exception) - Method in class org.apache.kafka.streams.errors.DefaultProductionExceptionHandler
 
handle(ProcessorContext, ConsumerRecord<byte[], byte[]>, Exception) - Method in interface org.apache.kafka.streams.errors.DeserializationExceptionHandler
Inspect a record and the exception received.
handle(ProcessorContext, ConsumerRecord<byte[], byte[]>, Exception) - Method in class org.apache.kafka.streams.errors.LogAndContinueExceptionHandler
 
handle(ProcessorContext, ConsumerRecord<byte[], byte[]>, Exception) - Method in class org.apache.kafka.streams.errors.LogAndFailExceptionHandler
 
handle(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 whether or not to continue processing.
hashCode() - Method in class org.apache.kafka.streams.KeyValue
 
hashCode() - Method in class org.apache.kafka.streams.kstream.JoinWindows
 
hashCode() - Method in class org.apache.kafka.streams.kstream.SessionWindows
 
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.processor.TaskId
 
hashCode() - Method in class org.apache.kafka.streams.processor.TaskMetadata
 
hashCode() - Method in class org.apache.kafka.streams.processor.ThreadMetadata
 
hashCode() - Method in class org.apache.kafka.streams.processor.TopologyBuilder.TopicsInfo
Deprecated.
 
hashCode() - Method in class org.apache.kafka.streams.state.HostInfo
 
hashCode() - Method in class org.apache.kafka.streams.state.StreamsMetadata
 
host() - Method in class org.apache.kafka.streams.state.HostInfo
 
host() - Method in class org.apache.kafka.streams.state.StreamsMetadata
 
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
 
hostInfo() - Method in class org.apache.kafka.streams.state.StreamsMetadata
 

I

id - Variable in enum org.apache.kafka.streams.errors.DeserializationExceptionHandler.DeserializationHandlerResponse
the permanent and immutable id of an API--this can't change ever
id - Variable in enum org.apache.kafka.streams.errors.ProductionExceptionHandler.ProductionExceptionHandlerResponse
the permanent and immutable id of an API--this can't change ever
id() - Method in interface org.apache.kafka.streams.TopologyDescription.GlobalStore
 
id() - Method in interface org.apache.kafka.streams.TopologyDescription.Subtopology
Internally assigned unique ID.
inactivityGap() - Method in class org.apache.kafka.streams.kstream.SessionWindows
Return the specified gap for the session windows in milliseconds.
init(ProcessorContext) - Method in interface org.apache.kafka.streams.kstream.Transformer
Initialize this transformer.
init(ProcessorContext) - Method in interface org.apache.kafka.streams.kstream.ValueTransformer
Initialize this transformer.
init(ProcessorContext) - Method in interface org.apache.kafka.streams.kstream.ValueTransformerWithKey
Initialize this transformer.
init(ProcessorContext) - Method in class org.apache.kafka.streams.processor.AbstractProcessor
 
init(ProcessorContext) - Method in interface org.apache.kafka.streams.processor.Processor
Initialize this processor with the given context.
init(ProcessorContext, StateStore) - Method in interface org.apache.kafka.streams.processor.StateStore
Initializes this state store
Initializer<VA> - Interface in org.apache.kafka.streams.kstream
The Initializer interface for creating an initial value in aggregations.
inMemory() - Method in interface org.apache.kafka.streams.state.Stores.KeyValueFactory
Keep all key-value entries in-memory, although for durability all entries are recorded in a Kafka topic that can be read to restore the entries if they are lost.
inMemoryKeyValueStore(String) - Static method in class org.apache.kafka.streams.state.Stores
Create an in-memory KeyValueBytesStoreSupplier.
internalTopologyBuilder - Variable in class org.apache.kafka.streams.processor.TopologyBuilder
Deprecated.
NOTE this member would not needed by developers working with the processor APIs, but only used for internal functionalities.
InvalidStateStoreException - Exception in org.apache.kafka.streams.errors
Indicates that there was a problem when trying to access a StateStore, i.e, the Store is no longer valid because it is closed or doesn't exist any more due to a rebalance.
InvalidStateStoreException(String) - Constructor for exception org.apache.kafka.streams.errors.InvalidStateStoreException
 
InvalidStateStoreException(String, Throwable) - Constructor for exception org.apache.kafka.streams.errors.InvalidStateStoreException
 
InvalidStateStoreException(Throwable) - Constructor for exception org.apache.kafka.streams.errors.InvalidStateStoreException
 
isOpen() - Method in interface org.apache.kafka.streams.processor.StateStore
Is this store open for reading and writing
isRunning() - Method in enum org.apache.kafka.streams.KafkaStreams.State
 
isValidTransition(KafkaStreams.State) - Method in enum org.apache.kafka.streams.KafkaStreams.State
 

J

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, Joined<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 with default serializers and deserializers.
join(KStream<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, JoinWindows, Serde<K>, Serde<V>, Serde<VO>) - Method in interface org.apache.kafka.streams.kstream.KStream
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>, ValueJoiner<? super V, ? super VT, ? extends VR>, Serde<K>, Serde<V>) - Method in interface org.apache.kafka.streams.kstream.KStream
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(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 another KTable's records using non-windowed inner equi join.
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 another KTable's records using non-windowed inner equi join.
join(KTable<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, Serde<VR>, String) - Method in interface org.apache.kafka.streams.kstream.KTable
join(KTable<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, StateStoreSupplier<KeyValueStore>) - Method in interface org.apache.kafka.streams.kstream.KTable
Joined<K,V,VO> - Class in org.apache.kafka.streams.kstream
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 a KafkaStreams instance.
KafkaStreams - Class in org.apache.kafka.streams
A Kafka client that allows for performing continuous computation on input coming from one or more input topics and sends output to zero, one, or more output topics.
KafkaStreams(TopologyBuilder, Properties) - Constructor for class org.apache.kafka.streams.KafkaStreams
KafkaStreams(TopologyBuilder, StreamsConfig) - Constructor for class org.apache.kafka.streams.KafkaStreams
KafkaStreams(TopologyBuilder, StreamsConfig, KafkaClientSupplier) - Constructor for class org.apache.kafka.streams.KafkaStreams
KafkaStreams(Topology, Properties) - Constructor for class org.apache.kafka.streams.KafkaStreams
Create a KafkaStreams instance.
KafkaStreams(Topology, StreamsConfig) - Constructor for class org.apache.kafka.streams.KafkaStreams
Create a KafkaStreams instance.
KafkaStreams(Topology, StreamsConfig, KafkaClientSupplier) - Constructor for class org.apache.kafka.streams.KafkaStreams
Create a KafkaStreams instance.
KafkaStreams(Topology, StreamsConfig, Time) - Constructor for class org.apache.kafka.streams.KafkaStreams
Create a KafkaStreams instance.
KafkaStreams.State - Enum in org.apache.kafka.streams
Kafka Streams states are the possible state that a Kafka Streams instance can be in.
KafkaStreams.StateListener - Interface in org.apache.kafka.streams
Listen to KafkaStreams.State change events.
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_SERDE_CLASS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
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.
keySerde - Variable in class org.apache.kafka.streams.Consumed
 
keySerde(Serde<K>) - Static method in class org.apache.kafka.streams.kstream.Joined
Create an instance of Joined with a key Serde.
keySerde() - Method in class org.apache.kafka.streams.kstream.Joined
 
keySerde - Variable in class org.apache.kafka.streams.kstream.Materialized
 
keySerde - Variable in class org.apache.kafka.streams.kstream.Produced
 
keySerde(Serde<K>) - Static method in class org.apache.kafka.streams.kstream.Produced
Create a Produced instance with provided keySerde.
keySerde - Variable in class org.apache.kafka.streams.kstream.Serialized
 
keySerde() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
Returns the default key serde
keySerde() - Method in class org.apache.kafka.streams.state.StateSerdes
Return the key serde.
keySerde() - Method in class org.apache.kafka.streams.StreamsConfig
Deprecated.
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 instances of type <Byte, byte[]>.
KeyValueIterator<K,V> - Interface in org.apache.kafka.streams.state
Iterator interface of KeyValue.
KeyValueMapper<K,V,VR> - Interface in org.apache.kafka.streams.kstream
The KeyValueMapper interface for mapping a key-value pair to a new value of arbitrary type.
KeyValueStore<K,V> - Interface in org.apache.kafka.streams.state
A key-value store that supports put/get/delete and range queries.
keyValueStore() - Static method in class org.apache.kafka.streams.state.QueryableStoreTypes
keyValueStoreBuilder(KeyValueBytesStoreSupplier, Serde<K>, Serde<V>) - Static method in class org.apache.kafka.streams.state.Stores
Creates a StoreBuilder than can be used to build a KeyValueStore.
KGroupedStream<K,V> - Interface in org.apache.kafka.streams.kstream
KGroupedStream is an abstraction of a grouped record stream of KeyValue pairs.
KGroupedTable<K,V> - Interface in org.apache.kafka.streams.kstream
KGroupedTable is an abstraction of a re-grouped changelog stream from a primary-keyed table, usually on a different grouping key than the original primary key.
KStream<K,V> - Interface in org.apache.kafka.streams.kstream
KStream is an abstraction of a record stream of KeyValue pairs, i.e., each record is an independent entity/event in the real world.
KStreamBuilder - Class in org.apache.kafka.streams.kstream
Deprecated.
Use StreamsBuilder instead
KStreamBuilder() - Constructor for class org.apache.kafka.streams.kstream.KStreamBuilder
Deprecated.
 
KTable<K,V> - Interface in org.apache.kafka.streams.kstream
KTable is an abstraction of a changelog stream from a primary-keyed table.

L

label - Variable in class org.apache.kafka.streams.kstream.Printed
 
latestResetTopicsPattern() - Method in class org.apache.kafka.streams.processor.TopologyBuilder
Deprecated.
Get the Pattern to match all topics requiring to start reading from latest available offset NOTE this function would not needed by developers working with the processor APIs, but only used for the high-level DSL parsing functionalities.
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, Joined<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 with default serializers and deserializers.
leftJoin(KStream<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, JoinWindows, Serde<K>, Serde<V>, Serde<VO>) - Method in interface org.apache.kafka.streams.kstream.KStream
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>, ValueJoiner<? super V, ? super VT, ? extends VR>, Serde<K>, Serde<V>) - Method in interface org.apache.kafka.streams.kstream.KStream
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(KTable<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>) - Method in interface org.apache.kafka.streams.kstream.KTable
Join records of this KTable (left input) with another KTable's (right input) records using non-windowed left equi join.
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 another KTable's (right input) records using non-windowed left equi join.
leftJoin(KTable<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, Serde<VR>, String) - Method in interface org.apache.kafka.streams.kstream.KTable
leftJoin(KTable<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, StateStoreSupplier<KeyValueStore>) - Method in interface org.apache.kafka.streams.kstream.KTable
localThreadsMetadata() - Method in class org.apache.kafka.streams.KafkaStreams
Returns runtime information about the local threads of this KafkaStreams instance.
LockException - Exception 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 org.apache.kafka.streams.errors.LockException
 
LockException(String, Throwable) - Constructor for exception org.apache.kafka.streams.errors.LockException
 
LockException(Throwable) - Constructor for exception org.apache.kafka.streams.errors.LockException
 
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
 
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
 
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.processor.StateStoreSupplier
Deprecated.
Returns a Map containing any log configs that will be used when creating the changelog for the StateStore
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 - Variable in class org.apache.kafka.streams.kstream.Materialized
 
loggingEnabled() - Method in interface org.apache.kafka.streams.processor.StateStoreSupplier
Deprecated.
 
loggingEnabled() - Method in interface org.apache.kafka.streams.state.StoreBuilder
 
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
 
maintainMs() - Method in class org.apache.kafka.streams.kstream.JoinWindows
Return the window maintain duration (retention time) in milliseconds.
maintainMs() - Method in class org.apache.kafka.streams.kstream.SessionWindows
Return the window maintain duration (retention time) in milliseconds.
maintainMs() - Method in class org.apache.kafka.streams.kstream.TimeWindows
Return the window maintain duration (retention time) in milliseconds.
maintainMs() - Method in class org.apache.kafka.streams.kstream.UnlimitedWindows
Return the window maintain duration (retention time) in milliseconds.
maintainMs() - Method in class org.apache.kafka.streams.kstream.Windows
Return the window maintain duration (retention time) in milliseconds.
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).
mapper - Variable in class org.apache.kafka.streams.kstream.Printed
 
mapValues(ValueMapper<? super V, ? extends VR>) - Method in interface org.apache.kafka.streams.kstream.KStream
Transform the value of each input record into a new value (with possible new type) of the output record.
mapValues(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(ValueMapper<? super V, ? extends VR>) - Method in interface org.apache.kafka.streams.kstream.KTable
Create a new KTable by transforming the value of each record in this KTable into a new value (with possible new type) in the new KTable.
mapValues(ValueMapperWithKey<? super K, ? super V, ? extends VR>) - Method in interface org.apache.kafka.streams.kstream.KTable
Create a new KTable by transforming the value of each record in this KTable into a new value (with possible new type) in the new KTable.
mapValues(ValueMapper<? super V, ? extends VR>, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KTable
Create a new KTable by transforming the value of each record in this KTable into a new value (with possible new type) in the new KTable.
mapValues(ValueMapperWithKey<? super K, ? super V, ? extends VR>, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KTable
Create a new KTable by transforming the value of each record in this KTable into a new value (with possible new type) in the new KTable.
mapValues(ValueMapper<? super V, ? extends VR>, Serde<VR>, String) - Method in interface org.apache.kafka.streams.kstream.KTable
mapValues(ValueMapper<? super V, ? extends VR>, Serde<VR>, StateStoreSupplier<KeyValueStore>) - Method in interface org.apache.kafka.streams.kstream.KTable
Materialized<K,V,S extends StateStore> - Class in org.apache.kafka.streams.kstream
Used to describe how a StateStore should be materialized.
Materialized(Materialized<K, V, S>) - Constructor for class org.apache.kafka.streams.kstream.Materialized
Copy constructor.
maxEntries(int) - Method in interface org.apache.kafka.streams.state.Stores.InMemoryKeyValueFactory
Deprecated.
Limits the in-memory key-value store to hold a maximum number of entries.
maxNumPartitions(Cluster, Set<String>) - Method in class org.apache.kafka.streams.processor.DefaultPartitionGrouper
 
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>...) - Method in class org.apache.kafka.streams.kstream.KStreamBuilder
Deprecated.
Create a new instance of KStream by merging the given KStreams.
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
metadataForKey(String, K, Serializer<K>) - Method in class org.apache.kafka.streams.KafkaStreams
Find the currently running KafkaStreams instance (potentially remotely) that use the same application ID as this instance (i.e., all instances that belong to the same Kafka Streams application) and that contain a StateStore with the given storeName and the StateStore contains the given key and return StreamsMetadata for it.
metadataForKey(String, K, StreamPartitioner<? super K, ?>) - Method in class org.apache.kafka.streams.KafkaStreams
Find the currently running KafkaStreams instance (potentially remotely) that use the same application ID as this instance (i.e., all instances that belong to the same Kafka Streams application) and that contain a StateStore with the given storeName and the StateStore contains the given key and return StreamsMetadata for it.
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.
metrics() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
Returns Metrics instance
metrics() - Method in interface org.apache.kafka.streams.StreamsMetrics
Get read-only handle on global metrics registry.
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.
migratedTask() - Method in exception org.apache.kafka.streams.errors.TaskMigratedException
 

N

name - Variable in enum org.apache.kafka.streams.errors.DeserializationExceptionHandler.DeserializationHandlerResponse
an english description of the api--this is for debugging and can change
name - Variable in enum org.apache.kafka.streams.errors.ProductionExceptionHandler.ProductionExceptionHandlerResponse
an english description of the api--this is for debugging and can change
name() - Method in interface org.apache.kafka.streams.processor.StateStore
The name of this store.
name() - Method in interface org.apache.kafka.streams.processor.StateStoreSupplier
Deprecated.
Return the name of this state store supplier.
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.
newName(String) - Method in class org.apache.kafka.streams.kstream.KStreamBuilder
Deprecated.
This function is only for internal usage only and should not be called.
newStoreName(String) - Method in class org.apache.kafka.streams.kstream.KStreamBuilder
Deprecated.
This function is only for internal usage only and should not be called.
nodeGroups() - Method in class org.apache.kafka.streams.processor.TopologyBuilder
Deprecated.
Returns the map of node groups keyed by the topic group id.
nodes() - Method in interface org.apache.kafka.streams.TopologyDescription.Subtopology
All nodes of this sub-topology.
NOT_AVAILABLE - Static variable in class org.apache.kafka.streams.state.StreamsMetadata
Sentinel to indicate that the StreamsMetadata is currently unavailable.
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

O

of(long) - Static method in class org.apache.kafka.streams.kstream.JoinWindows
Specifies that records of the same key are joinable if their timestamps are within timeDifferenceMs, i.e., the timestamp of a record from the secondary stream is max timeDifferenceMs earlier or later than the timestamp of the record from the primary stream.
of(long) - 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.
of() - Static method in class org.apache.kafka.streams.kstream.UnlimitedWindows
Return an unlimited window starting at timestamp zero.
offset() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
Returns the offset of the current input record; could be -1 if it is not available (for example, if this method is invoked from the punctuate call)
onBatchRestored(TopicPartition, String, long, long) - Method in class org.apache.kafka.streams.processor.AbstractNotifyingBatchingRestoreCallback
 
onBatchRestored(TopicPartition, String, long, long) - Method in class org.apache.kafka.streams.processor.AbstractNotifyingRestoreCallback
 
onBatchRestored(TopicPartition, String, long, long) - Method in interface org.apache.kafka.streams.processor.StateRestoreListener
Method called after restoring a batch of records.
onChange(KafkaStreams.State, KafkaStreams.State) - Method in interface org.apache.kafka.streams.KafkaStreams.StateListener
Called when state changes.
onInvalidTimestamp(ConsumerRecord<Object, Object>, long, long) - Method in class org.apache.kafka.streams.processor.FailOnInvalidTimestamp
Raises an exception on every call.
onInvalidTimestamp(ConsumerRecord<Object, Object>, long, long) - Method in class org.apache.kafka.streams.processor.LogAndSkipOnInvalidTimestamp
Writes a log WARN message when the extracted timestamp is invalid (negative) but returns the invalid timestamp as-is, which ultimately causes the record to be skipped and not to be processed.
onInvalidTimestamp(ConsumerRecord<Object, Object>, long, long) - Method in class org.apache.kafka.streams.processor.UsePreviousTimeOnInvalidTimestamp
Returns the current stream-time as new timestamp for the record.
onRestoreEnd(TopicPartition, String, long) - Method in class org.apache.kafka.streams.processor.AbstractNotifyingBatchingRestoreCallback
 
onRestoreEnd(TopicPartition, String, long) - Method in class org.apache.kafka.streams.processor.AbstractNotifyingRestoreCallback
 
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 class org.apache.kafka.streams.processor.AbstractNotifyingBatchingRestoreCallback
 
onRestoreStart(TopicPartition, String, long, long) - Method in class org.apache.kafka.streams.processor.AbstractNotifyingRestoreCallback
 
onRestoreStart(TopicPartition, String, long, long) - Method in interface org.apache.kafka.streams.processor.StateRestoreListener
Method called at the very beginning of StateStore restoration.
org.apache.kafka.streams - package org.apache.kafka.streams
 
org.apache.kafka.streams.errors - package org.apache.kafka.streams.errors
 
org.apache.kafka.streams.kstream - package org.apache.kafka.streams.kstream
 
org.apache.kafka.streams.processor - package org.apache.kafka.streams.processor
 
org.apache.kafka.streams.state - package org.apache.kafka.streams.state
 
otherValueSerde(Serde<VO>) - Static method in class org.apache.kafka.streams.kstream.Joined
Create an instance of Joined with an other value Serde.
otherValueSerde() - Method in class org.apache.kafka.streams.kstream.Joined
 
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, Joined<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 with default serializers and deserializers.
outerJoin(KStream<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, JoinWindows, Serde<K>, Serde<V>, Serde<VO>) - Method in interface org.apache.kafka.streams.kstream.KStream
outerJoin(KTable<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>) - Method in interface org.apache.kafka.streams.kstream.KTable
Join records of this KTable (left input) with another KTable's (right input) records using non-windowed outer equi join.
outerJoin(KTable<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KTable
Join records of this KTable (left input) with another KTable's (right input) records using non-windowed outer equi join.
outerJoin(KTable<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, Serde<VR>, String) - Method in interface org.apache.kafka.streams.kstream.KTable
outerJoin(KTable<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, StateStoreSupplier<KeyValueStore>) - Method in interface org.apache.kafka.streams.kstream.KTable
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
 
partition() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
Returns the partition id of the current input record; could be -1 if it is not available (for example, if this method is invoked from the punctuate call)
partition(K, V, int) - Method in interface org.apache.kafka.streams.processor.StreamPartitioner
Determine the partition number for a record with the given key and value and the current number of partitions.
partition - Variable in class org.apache.kafka.streams.processor.TaskId
The ID of the partition.
PARTITION_GROUPER_CLASS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
partition.grouper
partitioner - Variable in class org.apache.kafka.streams.kstream.Produced
 
PartitionGrouper - Interface in org.apache.kafka.streams.processor
A partition grouper that generates partition groups given the list of topic-partitions.
partitionGroups(Map<Integer, Set<String>>, Cluster) - Method in class org.apache.kafka.streams.processor.DefaultPartitionGrouper
Generate tasks with the assigned topic partitions.
partitionGroups(Map<Integer, Set<String>>, Cluster) - Method in interface org.apache.kafka.streams.processor.PartitionGrouper
Returns a map of task ids to groups of partitions.
peek(ForeachAction<? super K, ? super V>) - Method in interface org.apache.kafka.streams.kstream.KStream
Perform an action on each record of KStream.
peekNextKey() - Method in interface org.apache.kafka.streams.state.KeyValueIterator
Peek at the next key without advancing the iterator
persistent() - Method in interface org.apache.kafka.streams.processor.StateStore
Return if the storage is persistent or not.
persistent() - Method in interface org.apache.kafka.streams.state.Stores.KeyValueFactory
Keep all key-value entries off-heap in a local database, although for durability all entries are recorded in a Kafka topic that can be read to restore the entries if they are lost.
persistentKeyValueStore(String) - Static method in class org.apache.kafka.streams.state.Stores
Create a persistent KeyValueBytesStoreSupplier.
persistentSessionStore(String, long) - Static method in class org.apache.kafka.streams.state.Stores
Create a persistent SessionBytesStoreSupplier.
persistentWindowStore(String, long, int, long, 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 class org.apache.kafka.streams.state.StreamsMetadata
 
postProcessParsedConfig(Map<String, Object>) - Method in class org.apache.kafka.streams.StreamsConfig
 
predecessors() - Method in interface org.apache.kafka.streams.TopologyDescription.Node
The predecessors of this node within a sub-topology.
Predicate<K,V> - Interface in org.apache.kafka.streams.kstream
The Predicate interface represents a predicate (boolean-valued function) of a KeyValue pair.
print() - Method in interface org.apache.kafka.streams.kstream.KStream
Deprecated.
use print(Printed)
print(String) - Method in interface org.apache.kafka.streams.kstream.KStream
Deprecated.
print(Serde<K>, Serde<V>) - Method in interface org.apache.kafka.streams.kstream.KStream
print(Serde<K>, Serde<V>, String) - Method in interface org.apache.kafka.streams.kstream.KStream
print(KeyValueMapper<? super K, ? super V, String>) - Method in interface org.apache.kafka.streams.kstream.KStream
print(KeyValueMapper<? super K, ? super V, String>, String) - Method in interface org.apache.kafka.streams.kstream.KStream
print(KeyValueMapper<? super K, ? super V, String>, Serde<K>, Serde<V>) - Method in interface org.apache.kafka.streams.kstream.KStream
print(KeyValueMapper<? super K, ? super V, String>, Serde<K>, Serde<V>, String) - Method in interface org.apache.kafka.streams.kstream.KStream
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
print() - Method in interface org.apache.kafka.streams.kstream.KTable
Deprecated.
Use the Interactive Queries APIs (e.g., KafkaStreams.store(String, QueryableStoreType) followed by ReadOnlyKeyValueStore.all()) to iterate over the keys of a KTable. Alternatively convert to a KStream using KTable.toStream() and then use print(Printed.toSysOut()) on the result.
print(String) - Method in interface org.apache.kafka.streams.kstream.KTable
Deprecated.
Use the Interactive Queries APIs (e.g., KafkaStreams.store(String, QueryableStoreType) followed by ReadOnlyKeyValueStore.all()) to iterate over the keys of a KTable. Alternatively convert to a KStream using KTable.toStream() and then use print(Printed.toSysOut().withLabel(lable)) on the result.
print(Serde<K>, Serde<V>) - Method in interface org.apache.kafka.streams.kstream.KTable
Deprecated.
Use the Interactive Queries APIs (e.g., KafkaStreams.store(String, QueryableStoreType) followed by ReadOnlyKeyValueStore.all()) to iterate over the keys of a KTable. Alternatively convert to a KStream using KTable.toStream() and then use print(Printed.toSysOut().withKeyValueMapper(...) on the result.
print(Serde<K>, Serde<V>, String) - Method in interface org.apache.kafka.streams.kstream.KTable
Deprecated.
Use the Interactive Queries APIs (e.g., KafkaStreams.store(String, QueryableStoreType) followed by ReadOnlyKeyValueStore.all()) to iterate over the keys of a KTable. Alternatively convert to a KStream using KTable.toStream() and then use print(Printed.toSysOut().withLabel(label).withKeyValueMapper(...) on the result.
Printed<K,V> - Class in org.apache.kafka.streams.kstream
An object to define the options used when printing a KStream.
Printed(Printed<K, V>) - Constructor for class org.apache.kafka.streams.kstream.Printed
Copy constructor.
printWriter - Variable in class org.apache.kafka.streams.kstream.Printed
 
process(ProcessorSupplier<? super K, ? super V>, 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 given ProcessorSupplier).
process(K, V) - Method in interface org.apache.kafka.streams.processor.Processor
Process the record with the given key and value.
PROCESSING_GUARANTEE_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
processing.guarantee
Processor<K,V> - Interface in org.apache.kafka.streams.processor
A processor of key-value pair records.
processor() - Method in interface org.apache.kafka.streams.TopologyDescription.GlobalStore
The processor node maintaining the global store.
ProcessorContext - Interface in org.apache.kafka.streams.processor
Processor context interface.
ProcessorStateException - Exception in org.apache.kafka.streams.errors
Indicates a processor state operation (e.g.
ProcessorStateException(String) - Constructor for exception org.apache.kafka.streams.errors.ProcessorStateException
 
ProcessorStateException(String, Throwable) - Constructor for exception org.apache.kafka.streams.errors.ProcessorStateException
 
ProcessorStateException(Throwable) - Constructor for exception org.apache.kafka.streams.errors.ProcessorStateException
 
ProcessorSupplier<K,V> - Interface in org.apache.kafka.streams.processor
A processor supplier that can create one or more Processor instances.
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.through(String, Produced) or KStream.to(String, Produced).
Produced(Produced<K, V>) - Constructor for class org.apache.kafka.streams.kstream.Produced
 
PRODUCER_PREFIX - Static variable in class org.apache.kafka.streams.StreamsConfig
Prefix used to isolate producer configs from other client configs.
producerPrefix(String) - Static method in class org.apache.kafka.streams.StreamsConfig
Prefix a property with StreamsConfig.PRODUCER_PREFIX.
ProductionExceptionHandler - Interface in org.apache.kafka.streams.errors
Interface that specifies how an exception when attempting to produce a result to Kafka should be handled.
ProductionExceptionHandler.ProductionExceptionHandlerResponse - Enum in org.apache.kafka.streams.errors
 
punctuate(long) - Method in interface org.apache.kafka.streams.kstream.Transformer
Deprecated.
Please use Punctuator functional interface instead.
punctuate(long) - Method in interface org.apache.kafka.streams.kstream.ValueTransformer
Deprecated.
Please use Punctuator functional interface instead.
punctuate(long) - Method in class org.apache.kafka.streams.processor.AbstractProcessor
Perform any periodic operations, if this processor schedule itself with the context during initialization.
punctuate(long) - Method in interface org.apache.kafka.streams.processor.Processor
Deprecated.
Please use Punctuator functional interface instead.
punctuate(long) - Method in interface org.apache.kafka.streams.processor.Punctuator
Perform the scheduled periodic operation.
PunctuationType - Enum in org.apache.kafka.streams.processor
Controls what notion of time is used for punctuation scheduled via ProcessorContext.schedule(long, PunctuationType, Punctuator) schedule}: STREAM_TIME - uses "stream time", which is advanced by the processing of messages in accordance with the timestamp as extracted by the TimestampExtractor in use.
Punctuator - Interface in org.apache.kafka.streams.processor
A functional interface used as an argument to ProcessorContext.schedule(long, PunctuationType, Punctuator).
put(K, V) - Method in interface org.apache.kafka.streams.state.KeyValueStore
Update the value associated with this key
put(Windowed<K>, AGG) - Method in interface org.apache.kafka.streams.state.SessionStore
Write the aggregated value for the provided key to the store
put(K, V) - Method in interface org.apache.kafka.streams.state.WindowStore
Put a key-value pair with the current wall-clock time as the timestamp into the corresponding window
put(K, V, long) - Method in interface org.apache.kafka.streams.state.WindowStore
Put a key-value pair with the given timestamp into the corresponding window
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

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<T> - Interface in org.apache.kafka.streams.state
Used to enable querying of custom StateStore types via the KafkaStreams API.
QueryableStoreTypes - Class in org.apache.kafka.streams.state
Provides access to the QueryableStoreTypes provided with KafkaStreams.
QueryableStoreTypes() - Constructor for class org.apache.kafka.streams.state.QueryableStoreTypes
 

R

range(K, K) - Method in interface org.apache.kafka.streams.state.ReadOnlyKeyValueStore
Get an iterator over a given range of keys.
rawKey(K) - Method in class org.apache.kafka.streams.state.StateSerdes
Serialize the given key.
rawValue(V) - Method in class org.apache.kafka.streams.state.StateSerdes
Serialize the given value.
readFrom(DataInputStream) - Static method in class org.apache.kafka.streams.processor.TaskId
 
readFrom(ByteBuffer) - Static method in class org.apache.kafka.streams.processor.TaskId
 
ReadOnlyKeyValueStore<K,V> - Interface in org.apache.kafka.streams.state
A key value store that only supports read operations.
ReadOnlySessionStore<K,AGG> - Interface in org.apache.kafka.streams.state
A session store that only supports read operations.
ReadOnlyWindowStore<K,V> - Interface in org.apache.kafka.streams.state
A window store that only supports read operations Implementations should be thread-safe as concurrent reads and writes are expected.
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
recordLatency(Sensor, long, long) - Method in interface org.apache.kafka.streams.StreamsMetrics
Record the given latency value of the sensor.
recordThroughput(Sensor, long) - Method in interface org.apache.kafka.streams.StreamsMetrics
Record the throughput value of a sensor.
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>, String) - Method in interface org.apache.kafka.streams.kstream.KGroupedStream
reduce(Reducer<V>, StateStoreSupplier<KeyValueStore>) - Method in interface org.apache.kafka.streams.kstream.KGroupedStream
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>, Windows<W>, String) - Method in interface org.apache.kafka.streams.kstream.KGroupedStream
reduce(Reducer<V>, Windows<W>) - Method in interface org.apache.kafka.streams.kstream.KGroupedStream
Deprecated.
reduce(Reducer<V>, Windows<W>, StateStoreSupplier<WindowStore>) - Method in interface org.apache.kafka.streams.kstream.KGroupedStream
reduce(Reducer<V>, SessionWindows, String) - Method in interface org.apache.kafka.streams.kstream.KGroupedStream
reduce(Reducer<V>, SessionWindows) - Method in interface org.apache.kafka.streams.kstream.KGroupedStream
Deprecated.
reduce(Reducer<V>, SessionWindows, StateStoreSupplier<SessionStore>) - Method in interface org.apache.kafka.streams.kstream.KGroupedStream
reduce(Reducer<V>, Reducer<V>, String) - 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
Combine the value of records of the original KTable that got mapped to the same key into a new instance of KTable.
reduce(Reducer<V>, Reducer<V>) - Method in interface org.apache.kafka.streams.kstream.KGroupedTable
Combine the value of records of the original KTable that got mapped to the same key into a new instance of KTable.
reduce(Reducer<V>, Reducer<V>, StateStoreSupplier<KeyValueStore>) - Method in interface org.apache.kafka.streams.kstream.KGroupedTable
reduce(Reducer<V>) - Method in interface org.apache.kafka.streams.kstream.SessionWindowedKStream
Combine values of this stream by the grouped key into SessionWindows.
reduce(Reducer<V>, Materialized<K, V, SessionStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.SessionWindowedKStream
Combine values of this stream by the grouped key into SessionWindows.
reduce(Reducer<V>) - Method in interface org.apache.kafka.streams.kstream.TimeWindowedKStream
Combine the values of records in this stream by the grouped key.
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.
Reducer<V> - Interface in org.apache.kafka.streams.kstream
The Reducer interface for combining two values of the same type into a new value.
register(StateStore, boolean, StateRestoreCallback) - Method in interface org.apache.kafka.streams.processor.ProcessorContext
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.
repartitionSourceTopics - Variable in class org.apache.kafka.streams.processor.TopologyBuilder.TopicsInfo
Deprecated.
 
REPLICATION_FACTOR_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
replication.factor
REQUEST_TIMEOUT_MS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
request.timeout.ms
resetPolicy - Variable in class org.apache.kafka.streams.Consumed
 
restore(byte[], byte[]) - Method in class org.apache.kafka.streams.processor.AbstractNotifyingBatchingRestoreCallback
Single put restore operations not supported, please use AbstractNotifyingRestoreCallback or StateRestoreCallback instead for single action restores.
restore(byte[], byte[]) - Method in interface org.apache.kafka.streams.processor.StateRestoreCallback
 
restoreAll(Collection<KeyValue<byte[], byte[]>>) - Method in interface org.apache.kafka.streams.processor.BatchingStateRestoreCallback
Called to restore a number of records.
retainDuplicates() - Method in interface org.apache.kafka.streams.state.WindowBytesStoreSupplier
Whether or not this store is retaining duplicate keys.
retentionPeriod() - Method in interface org.apache.kafka.streams.state.WindowBytesStoreSupplier
The time period for which the WindowStore will retain historic data.
RETRIES_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
retries
RETRY_BACKOFF_MS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
retry.backoff.ms
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.

S

schedule(long, PunctuationType, Punctuator) - Method in interface org.apache.kafka.streams.processor.ProcessorContext
Schedules a periodic operation for processors.
schedule(long) - Method in interface org.apache.kafka.streams.processor.ProcessorContext
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.
segments - Variable in class org.apache.kafka.streams.kstream.Windows
 
segments(int) - Method in class org.apache.kafka.streams.kstream.Windows
Set the number of segments to be used for rolling the window store.
segments() - Method in interface org.apache.kafka.streams.state.WindowBytesStoreSupplier
The number of segments 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.
SEND_BUFFER_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
send.buffer.bytes
Serialized<K,V> - Class in org.apache.kafka.streams.kstream
The class that is used to capture the key and value Serdes used when performing KStream.groupBy(KeyValueMapper, Serialized) and KStream.groupByKey(Serialized) operations.
Serialized(Serialized<K, V>) - Constructor for class org.apache.kafka.streams.kstream.Serialized
 
SessionBytesStoreSupplier - Interface in org.apache.kafka.streams.state
A store supplier that can be used to create one or more SessionStore instances of type <Byte, byte[]>.
sessionStore() - Static method in class org.apache.kafka.streams.state.QueryableStoreTypes
SessionStore<K,AGG> - Interface in org.apache.kafka.streams.state
Interface for storing the aggregated values of sessions
sessionStoreBuilder(SessionBytesStoreSupplier, Serde<K>, Serde<V>) - Static method in class org.apache.kafka.streams.state.Stores
Creates a StoreBuilder that can be used to build a SessionStore.
sessionWindowed(long) - Method in interface org.apache.kafka.streams.state.Stores.PersistentKeyValueFactory
Deprecated.
Set the persistent store as a SessionStore for use with SessionWindows
SessionWindowedKStream<K,V> - Interface in org.apache.kafka.streams.kstream
SessionWindowedKStream is an abstraction of a windowed record stream of KeyValue pairs.
SessionWindows - Class in org.apache.kafka.streams.kstream
A session based window specification used for aggregating events into sessions.
setApplicationId(String) - Method in class org.apache.kafka.streams.processor.TopologyBuilder
Deprecated.
This class is not part of public API and should never be used by a developer.
setConfig(String, Options, Map<String, Object>) - Method in interface org.apache.kafka.streams.state.RocksDBConfigSetter
Set the rocks db options for the provided storeName.
setGlobalStateRestoreListener(StateRestoreListener) - Method in class org.apache.kafka.streams.KafkaStreams
Set the listener which is triggered whenever a StateStore is being restored in order to resume processing.
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.
setUncaughtExceptionHandler(Thread.UncaughtExceptionHandler) - Method in class org.apache.kafka.streams.KafkaStreams
Set the handler invoked when a internal thread abruptly terminates due to an uncaught exception.
sinkTopics - Variable in class org.apache.kafka.streams.processor.TopologyBuilder.TopicsInfo
Deprecated.
 
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.
source() - Method in interface org.apache.kafka.streams.TopologyDescription.GlobalStore
The source node reading from a "global" topic.
sourceTopicPattern() - Method in class org.apache.kafka.streams.processor.TopologyBuilder
Deprecated.
NOTE this function would not needed by developers working with the processor APIs, but only used for the high-level DSL parsing functionalities.
sourceTopics - Variable in class org.apache.kafka.streams.processor.TopologyBuilder.TopicsInfo
Deprecated.
 
standbyTasks() - Method in class org.apache.kafka.streams.processor.ThreadMetadata
 
start() - Method in class org.apache.kafka.streams.KafkaStreams
Start the KafkaStreams instance by starting all its threads.
start() - Method in class org.apache.kafka.streams.kstream.Window
Return the start timestamp of this window.
startMs - Variable in class org.apache.kafka.streams.kstream.UnlimitedWindows
The start timestamp of the window.
startMs - Variable in class org.apache.kafka.streams.kstream.Window
 
startOn(long) - Method in class org.apache.kafka.streams.kstream.UnlimitedWindows
Return a new unlimited window for the specified start timestamp.
state() - Method in class org.apache.kafka.streams.KafkaStreams
Return the current KafkaStreams.State of this KafkaStreams 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
stateChangelogTopics - Variable in class org.apache.kafka.streams.processor.TopologyBuilder.TopicsInfo
Deprecated.
 
stateDir() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
Returns the state directory for the partition.
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.
stateStoreNames() - Method in class org.apache.kafka.streams.state.StreamsMetadata
 
stateStoreNameToSourceTopics() - Method in class org.apache.kafka.streams.processor.TopologyBuilder
Deprecated.
NOTE this function would not needed by developers working with the processor APIs, but only used for the high-level DSL parsing functionalities.
StateStoreSupplier<T extends StateStore> - Interface in org.apache.kafka.streams.processor
Deprecated.
store(String, QueryableStoreType<T>) - Method in class org.apache.kafka.streams.KafkaStreams
Get a facade wrapping the local StateStore instances with the provided storeName if the Store's type is accepted by the provided queryableStoreType.
StoreBuilder<T extends StateStore> - Interface in org.apache.kafka.streams.state
Build a StateStore wrapped with optional caching and logging.
storeName - Variable in class org.apache.kafka.streams.kstream.Materialized
 
Stores - Class in org.apache.kafka.streams.state
Factory for creating state stores in Kafka Streams.
Stores() - Constructor for class org.apache.kafka.streams.state.Stores
 
stores() - Method in interface org.apache.kafka.streams.TopologyDescription.Processor
The names of all connected stores.
Stores.InMemoryKeyValueFactory<K,V> - Interface in org.apache.kafka.streams.state
Deprecated.
Stores.KeyValueFactory<K,V> - Interface in org.apache.kafka.streams.state
 
Stores.PersistentKeyValueFactory<K,V> - Interface in org.apache.kafka.streams.state
Deprecated.
Stores.StoreFactory - Class in org.apache.kafka.streams.state
 
Stores.StoreFactory() - Constructor for class org.apache.kafka.streams.state.Stores.StoreFactory
 
Stores.ValueFactory<K> - Class in org.apache.kafka.streams.state
The factory for creating off-heap key-value stores.
Stores.ValueFactory() - Constructor for class org.apache.kafka.streams.state.Stores.ValueFactory
 
storeSupplier - Variable in class org.apache.kafka.streams.kstream.Materialized
 
StoreSupplier<T extends StateStore> - Interface in org.apache.kafka.streams.state
A state store supplier which can create one or more StateStore instances.
stream(String...) - Method in class org.apache.kafka.streams.kstream.KStreamBuilder
Deprecated.
Create a KStream from the specified topics.
stream(TopologyBuilder.AutoOffsetReset, String...) - Method in class org.apache.kafka.streams.kstream.KStreamBuilder
Deprecated.
Create a KStream from the specified topics.
stream(Pattern) - Method in class org.apache.kafka.streams.kstream.KStreamBuilder
Deprecated.
Create a KStream from the specified topic pattern.
stream(TopologyBuilder.AutoOffsetReset, Pattern) - Method in class org.apache.kafka.streams.kstream.KStreamBuilder
Deprecated.
Create a KStream from the specified topic pattern.
stream(Serde<K>, Serde<V>, String...) - Method in class org.apache.kafka.streams.kstream.KStreamBuilder
Deprecated.
Create a KStream from the specified topics.
stream(TopologyBuilder.AutoOffsetReset, Serde<K>, Serde<V>, String...) - Method in class org.apache.kafka.streams.kstream.KStreamBuilder
Deprecated.
Create a KStream from the specified topics.
stream(TimestampExtractor, Serde<K>, Serde<V>, String...) - Method in class org.apache.kafka.streams.kstream.KStreamBuilder
Deprecated.
Create a KStream from the specified topics.
stream(TopologyBuilder.AutoOffsetReset, TimestampExtractor, Serde<K>, Serde<V>, String...) - Method in class org.apache.kafka.streams.kstream.KStreamBuilder
Deprecated.
Create a KStream from the specified topics.
stream(Serde<K>, Serde<V>, Pattern) - Method in class org.apache.kafka.streams.kstream.KStreamBuilder
Deprecated.
Create a KStream from the specified topic pattern.
stream(TopologyBuilder.AutoOffsetReset, Serde<K>, Serde<V>, Pattern) - Method in class org.apache.kafka.streams.kstream.KStreamBuilder
Deprecated.
Create a KStream from the specified topic pattern.
stream(TimestampExtractor, Serde<K>, Serde<V>, Pattern) - Method in class org.apache.kafka.streams.kstream.KStreamBuilder
Deprecated.
Create a KStream from the specified topic pattern.
stream(TopologyBuilder.AutoOffsetReset, TimestampExtractor, Serde<K>, Serde<V>, Pattern) - Method in class org.apache.kafka.streams.kstream.KStreamBuilder
Deprecated.
Create a KStream from the specified topic pattern.
stream(String) - Method in class org.apache.kafka.streams.StreamsBuilder
Create a KStream from the specified topics.
stream(String, Consumed<K, V>) - Method in class org.apache.kafka.streams.StreamsBuilder
Create a KStream from the specified topics.
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.
streamPartitioner(StreamPartitioner<? super K, ? super V>) - Static method in class org.apache.kafka.streams.kstream.Produced
Create a Produced instance with provided partitioner.
StreamPartitioner<K,V> - Interface in org.apache.kafka.streams.processor
Determine how records are distributed among the partitions in a Kafka topic.
StreamsBuilder - Class in org.apache.kafka.streams
StreamsBuilder provide the high-level Kafka Streams DSL to specify a Kafka Streams topology.
StreamsBuilder() - Constructor for class org.apache.kafka.streams.StreamsBuilder
 
StreamsConfig - Class in org.apache.kafka.streams
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
 
StreamsConfig.InternalConfig() - Constructor for class org.apache.kafka.streams.StreamsConfig.InternalConfig
 
StreamsException - Exception in org.apache.kafka.streams.errors
StreamsException is the top-level exception type generated by Kafka Streams.
StreamsException(String) - Constructor for exception org.apache.kafka.streams.errors.StreamsException
 
StreamsException(String, Throwable) - Constructor for exception org.apache.kafka.streams.errors.StreamsException
 
StreamsException(Throwable) - Constructor for exception org.apache.kafka.streams.errors.StreamsException
 
StreamsMetadata - Class in org.apache.kafka.streams.state
Represents the state of an instance (process) in a KafkaStreams application.
StreamsMetadata(HostInfo, Set<String>, Set<TopicPartition>) - Constructor for class org.apache.kafka.streams.state.StreamsMetadata
 
StreamsMetrics - Interface in org.apache.kafka.streams
The Kafka Streams metrics interface for adding metric sensors and collecting metric values.
subscriptionUpdates() - Method in class org.apache.kafka.streams.processor.TopologyBuilder
Deprecated.
NOTE this function would not needed by developers working with the processor APIs, but only used for the high-level DSL parsing functionalities.
subtopologies() - Method in interface org.apache.kafka.streams.TopologyDescription
All sub-topologies of the represented topology.
successors() - Method in interface org.apache.kafka.streams.TopologyDescription.Node
The successor of this node within a sub-topology.

T

table(String, String) - Method in class org.apache.kafka.streams.kstream.KStreamBuilder
Deprecated.
Create a KTable for the specified topic.
table(String, StateStoreSupplier<KeyValueStore>) - Method in class org.apache.kafka.streams.kstream.KStreamBuilder
Deprecated.
Create a KTable for the specified topic.
table(String) - Method in class org.apache.kafka.streams.kstream.KStreamBuilder
Deprecated.
Create a KTable for the specified topic.
table(TopologyBuilder.AutoOffsetReset, String, String) - Method in class org.apache.kafka.streams.kstream.KStreamBuilder
Deprecated.
Create a KTable for the specified topic.
table(TopologyBuilder.AutoOffsetReset, String, StateStoreSupplier<KeyValueStore>) - Method in class org.apache.kafka.streams.kstream.KStreamBuilder
Deprecated.
Create a KTable for the specified topic.
table(TopologyBuilder.AutoOffsetReset, String) - Method in class org.apache.kafka.streams.kstream.KStreamBuilder
Deprecated.
Create a KTable for the specified topic.
table(TimestampExtractor, String, String) - Method in class org.apache.kafka.streams.kstream.KStreamBuilder
Deprecated.
Create a KTable for the specified topic.
table(TopologyBuilder.AutoOffsetReset, TimestampExtractor, String, String) - Method in class org.apache.kafka.streams.kstream.KStreamBuilder
Deprecated.
Create a KTable for the specified topic.
table(Serde<K>, Serde<V>, String, String) - Method in class org.apache.kafka.streams.kstream.KStreamBuilder
Deprecated.
Create a KTable for the specified topic.
table(Serde<K>, Serde<V>, String, StateStoreSupplier<KeyValueStore>) - Method in class org.apache.kafka.streams.kstream.KStreamBuilder
Deprecated.
Create a KTable for the specified topic.
table(Serde<K>, Serde<V>, String) - Method in class org.apache.kafka.streams.kstream.KStreamBuilder
Deprecated.
Create a KTable for the specified topic.
table(TopologyBuilder.AutoOffsetReset, Serde<K>, Serde<V>, String, String) - Method in class org.apache.kafka.streams.kstream.KStreamBuilder
Deprecated.
Create a KTable for the specified topic.
table(TimestampExtractor, Serde<K>, Serde<V>, String, String) - Method in class org.apache.kafka.streams.kstream.KStreamBuilder
Deprecated.
Create a KTable for the specified topic.
table(TopologyBuilder.AutoOffsetReset, TimestampExtractor, Serde<K>, Serde<V>, String, String) - Method in class org.apache.kafka.streams.kstream.KStreamBuilder
Deprecated.
Create a KTable for the specified topic.
table(TopologyBuilder.AutoOffsetReset, Serde<K>, Serde<V>, String) - Method in class org.apache.kafka.streams.kstream.KStreamBuilder
Deprecated.
Create a KTable for the specified topic.
table(TopologyBuilder.AutoOffsetReset, TimestampExtractor, Serde<K>, Serde<V>, String, StateStoreSupplier<KeyValueStore>) - Method in class org.apache.kafka.streams.kstream.KStreamBuilder
Deprecated.
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) - Method in class org.apache.kafka.streams.StreamsBuilder
Create a KTable for the specified topic.
table(String, Consumed<K, V>) - Method in class org.apache.kafka.streams.StreamsBuilder
Create a KTable for the specified topic.
table(String, Materialized<K, V, KeyValueStore<Bytes, byte[]>>) - Method in class org.apache.kafka.streams.StreamsBuilder
Create a KTable for the specified topic.
TASK_MANAGER_FOR_PARTITION_ASSIGNOR - Static variable in class org.apache.kafka.streams.StreamsConfig.InternalConfig
 
TaskAssignmentException - Exception in org.apache.kafka.streams.errors
Indicates a run time error incurred while trying to assign stream tasks to threads.
TaskAssignmentException(String) - Constructor for exception org.apache.kafka.streams.errors.TaskAssignmentException
 
TaskAssignmentException(String, Throwable) - Constructor for exception org.apache.kafka.streams.errors.TaskAssignmentException
 
TaskAssignmentException(Throwable) - Constructor for exception org.apache.kafka.streams.errors.TaskAssignmentException
 
taskId() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
Returns the task id
TaskId - Class in org.apache.kafka.streams.processor
The task ID representation composed as topic group ID plus the assigned partition ID.
TaskId(int, int) - Constructor for class org.apache.kafka.streams.processor.TaskId
 
taskId() - Method in class org.apache.kafka.streams.processor.TaskMetadata
 
TaskIdFormatException - Exception in org.apache.kafka.streams.errors
Indicates a run time error incurred while trying parse the task id from the read string.
TaskIdFormatException(String) - Constructor for exception org.apache.kafka.streams.errors.TaskIdFormatException
 
TaskIdFormatException(String, Throwable) - Constructor for exception org.apache.kafka.streams.errors.TaskIdFormatException
 
TaskIdFormatException(Throwable) - Constructor for exception org.apache.kafka.streams.errors.TaskIdFormatException
 
TaskMetadata - Class in org.apache.kafka.streams.processor
Represents the state of a single task running within a KafkaStreams application.
TaskMetadata(String, Set<TopicPartition>) - Constructor for class org.apache.kafka.streams.processor.TaskMetadata
 
TaskMigratedException - Exception in org.apache.kafka.streams.errors
Indicates that a task got migrated to another thread.
TaskMigratedException(Task) - Constructor for exception org.apache.kafka.streams.errors.TaskMigratedException
 
TaskMigratedException(Task, TopicPartition, long, long) - Constructor for exception org.apache.kafka.streams.errors.TaskMigratedException
 
TaskMigratedException(Task, Throwable) - Constructor for exception org.apache.kafka.streams.errors.TaskMigratedException
 
test(K, V) - Method in interface org.apache.kafka.streams.kstream.Predicate
Test if the record with the given key and value satisfies the predicate.
ThreadMetadata - Class in org.apache.kafka.streams.processor
Represents the state of a single thread running within a KafkaStreams application.
ThreadMetadata(String, String, Set<TaskMetadata>, Set<TaskMetadata>) - Constructor for class org.apache.kafka.streams.processor.ThreadMetadata
 
threadName() - Method in class org.apache.kafka.streams.processor.ThreadMetadata
 
threadState() - Method in class org.apache.kafka.streams.processor.ThreadMetadata
 
through(String) - Method in interface org.apache.kafka.streams.kstream.KStream
Materialize this stream to a topic and creates a new KStream from the topic using default serializers and deserializers and producer's DefaultPartitioner.
through(StreamPartitioner<? super K, ? super V>, String) - Method in interface org.apache.kafka.streams.kstream.KStream
through(Serde<K>, Serde<V>, String) - Method in interface org.apache.kafka.streams.kstream.KStream
through(Serde<K>, Serde<V>, StreamPartitioner<? super K, ? super V>, String) - Method in interface org.apache.kafka.streams.kstream.KStream
through(String, Produced<K, V>) - Method in interface org.apache.kafka.streams.kstream.KStream
Materialize this stream to a topic and creates a new KStream from the topic using the Produced instance for configuration of the key serde, value serde, and StreamPartitioner.
through(String, String) - Method in interface org.apache.kafka.streams.kstream.KTable
Deprecated.
through(String, StateStoreSupplier<KeyValueStore>) - Method in interface org.apache.kafka.streams.kstream.KTable
through(String) - Method in interface org.apache.kafka.streams.kstream.KTable
Deprecated.
use KTable.toStream() followed by to(topic) and and StreamsBuilder#table(topic) to read back as a KTable
through(StreamPartitioner<? super K, ? super V>, String) - Method in interface org.apache.kafka.streams.kstream.KTable
through(StreamPartitioner<? super K, ? super V>, String, String) - Method in interface org.apache.kafka.streams.kstream.KTable
through(StreamPartitioner<? super K, ? super V>, String, StateStoreSupplier<KeyValueStore>) - Method in interface org.apache.kafka.streams.kstream.KTable
through(Serde<K>, Serde<V>, String, String) - Method in interface org.apache.kafka.streams.kstream.KTable
through(Serde<K>, Serde<V>, String, StateStoreSupplier<KeyValueStore>) - Method in interface org.apache.kafka.streams.kstream.KTable
through(Serde<K>, Serde<V>, String) - Method in interface org.apache.kafka.streams.kstream.KTable
Deprecated.
through(Serde<K>, Serde<V>, StreamPartitioner<? super K, ? super V>, String, String) - Method in interface org.apache.kafka.streams.kstream.KTable
through(Serde<K>, Serde<V>, StreamPartitioner<? super K, ? super V>, String, StateStoreSupplier<KeyValueStore>) - Method in interface org.apache.kafka.streams.kstream.KTable
through(Serde<K>, Serde<V>, StreamPartitioner<? super K, ? super V>, String) - Method in interface org.apache.kafka.streams.kstream.KTable
timestamp() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
Returns the current timestamp.
TIMESTAMP_EXTRACTOR_CLASS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
timestampExtractor - Variable in class org.apache.kafka.streams.Consumed
 
TimestampExtractor - Interface in org.apache.kafka.streams.processor
An interface that allows the Kafka Streams framework to extract a timestamp from an instance of ConsumerRecord.
TimeWindowedKStream<K,V> - Interface in org.apache.kafka.streams.kstream
TimeWindowedKStream is an abstraction of a windowed record stream of KeyValue pairs.
TimeWindows - Class in org.apache.kafka.streams.kstream
The fixed-size time-based window specifications used for aggregations.
to(String) - Method in interface org.apache.kafka.streams.kstream.KStream
Materialize this stream to a topic using default serializers specified in the config and producer's DefaultPartitioner.
to(StreamPartitioner<? super K, ? super V>, String) - Method in interface org.apache.kafka.streams.kstream.KStream
to(Serde<K>, Serde<V>, String) - Method in interface org.apache.kafka.streams.kstream.KStream
to(Serde<K>, Serde<V>, StreamPartitioner<? super K, ? super V>, String) - Method in interface org.apache.kafka.streams.kstream.KStream
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(String) - Method in interface org.apache.kafka.streams.kstream.KTable
Deprecated.
to(StreamPartitioner<? super K, ? super V>, String) - Method in interface org.apache.kafka.streams.kstream.KTable
to(Serde<K>, Serde<V>, String) - Method in interface org.apache.kafka.streams.kstream.KTable
to(Serde<K>, Serde<V>, StreamPartitioner<? super K, ? super V>, String) - Method in interface org.apache.kafka.streams.kstream.KTable
toFile(String) - Static method in class org.apache.kafka.streams.kstream.Printed
Print the records of a KStream to a file.
topic() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
Returns the topic name of the current input record; could be null if it is not available (for example, if this method is invoked from the punctuate call)
topic() - Method in class org.apache.kafka.streams.state.StateSerdes
Return the topic.
topic() - Method in interface org.apache.kafka.streams.TopologyDescription.Sink
The topic name this sink node is writing to.
TOPIC_PREFIX - Static variable in class org.apache.kafka.streams.StreamsConfig
Prefix used to provide default topic configs to be applied when creating internal topics.
topicConfig - Variable in class org.apache.kafka.streams.kstream.Materialized
 
topicGroupId - Variable in class org.apache.kafka.streams.processor.TaskId
The ID of the topic group.
topicGroups() - Method in class org.apache.kafka.streams.processor.TopologyBuilder
Deprecated.
Returns the map of topic groups keyed by the group id.
topicPartitions() - Method in class org.apache.kafka.streams.processor.TaskMetadata
 
topicPartitions() - Method in class org.apache.kafka.streams.state.StreamsMetadata
 
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.
topics() - 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.AutoOffsetReset - Enum in org.apache.kafka.streams
Sets the auto.offset.reset configuration when adding a source processor or when creating KStream or KTable via StreamsBuilder.
TopologyBuilder - Class in org.apache.kafka.streams.processor
Deprecated.
use Topology instead
TopologyBuilder() - Constructor for class org.apache.kafka.streams.processor.TopologyBuilder
Deprecated.
Create a new builder.
TopologyBuilder.AutoOffsetReset - Enum in org.apache.kafka.streams.processor
Deprecated.
Enum used to define auto offset reset policy when creating KStream or KTable.
TopologyBuilder.TopicsInfo - Class in org.apache.kafka.streams.processor
Deprecated.
NOTE this class would not needed by developers working with the processor APIs, but only used for internal functionalities.
TopologyBuilder.TopicsInfo(Set<String>, Set<String>, Map<String, InternalTopicConfig>, Map<String, InternalTopicConfig>) - Constructor for class org.apache.kafka.streams.processor.TopologyBuilder.TopicsInfo
Deprecated.
 
TopologyBuilderException - Exception in org.apache.kafka.streams.errors
Deprecated.
use Topology instead of TopologyBuilder
TopologyBuilderException(String) - Constructor for exception org.apache.kafka.streams.errors.TopologyBuilderException
Deprecated.
 
TopologyBuilderException(String, Throwable) - Constructor for exception org.apache.kafka.streams.errors.TopologyBuilderException
Deprecated.
 
TopologyBuilderException(Throwable) - Constructor for exception org.apache.kafka.streams.errors.TopologyBuilderException
Deprecated.
 
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 in org.apache.kafka.streams.errors
Indicates a pre run time error occurred while parsing the logical topology to construct the physical processor topology.
TopologyException(String) - Constructor for exception org.apache.kafka.streams.errors.TopologyException
 
TopologyException(String, Throwable) - Constructor for exception org.apache.kafka.streams.errors.TopologyException
 
TopologyException(Throwable) - Constructor for exception org.apache.kafka.streams.errors.TopologyException
 
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 given KeyValueMapper to select the new key.
toString() - Method in class org.apache.kafka.streams.KafkaStreams
Deprecated.
Use KafkaStreams.localThreadsMetadata() to retrieve runtime information.
toString(String) - Method in class org.apache.kafka.streams.KafkaStreams
Deprecated.
Use KafkaStreams.localThreadsMetadata() to retrieve runtime information.
toString() - Method in class org.apache.kafka.streams.KeyValue
 
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.processor.TaskId
 
toString() - Method in class org.apache.kafka.streams.processor.TaskMetadata
 
toString() - Method in class org.apache.kafka.streams.processor.ThreadMetadata
 
toString() - Method in class org.apache.kafka.streams.processor.TopologyBuilder.TopicsInfo
Deprecated.
 
toString() - Method in class org.apache.kafka.streams.state.HostInfo
 
toString() - Method in class org.apache.kafka.streams.state.StreamsMetadata
 
toSysOut() - Static method in class org.apache.kafka.streams.kstream.Printed
Print the records of a KStream to system out.
transform(TransformerSupplier<? super K, ? super V, KeyValue<K1, V1>>, String...) - Method in interface org.apache.kafka.streams.kstream.KStream
Transform each record of the input stream into zero or more records in the output stream (both key and value type can be altered arbitrarily).
transform(K, V) - Method in interface org.apache.kafka.streams.kstream.Transformer
Transform the record with the given key and value.
transform(V) - Method in interface org.apache.kafka.streams.kstream.ValueTransformer
Transform the given value to a new value.
transform(K, V) - Method in interface org.apache.kafka.streams.kstream.ValueTransformerWithKey
Transform the given [key and ]value to a new value.
Transformer<K,V,R> - Interface in org.apache.kafka.streams.kstream
The Transformer interface is for stateful mapping of an input record to zero, one, or multiple new output records (both key and value type can be altered arbitrarily).
TransformerSupplier<K,V,R> - Interface in org.apache.kafka.streams.kstream
A TransformerSupplier interface which can create one or more Transformer instances.
transformValues(ValueTransformerSupplier<? super V, ? extends VR>, String...) - Method in interface org.apache.kafka.streams.kstream.KStream
Transform the value of each input record into a new value (with possible new type) of the output record.
transformValues(ValueTransformerWithKeySupplier<? super K, ? super V, ? extends VR>, String...) - Method in interface org.apache.kafka.streams.kstream.KStream
Transform the value of each input record into a new value (with possible new type) of the output record.

U

UnlimitedWindows - Class in org.apache.kafka.streams.kstream
The unlimited window specifications used for aggregations.
until(long) - Method in class org.apache.kafka.streams.kstream.JoinWindows
 
until(long) - Method in class org.apache.kafka.streams.kstream.SessionWindows
Set the window maintain duration (retention time) in milliseconds.
until(long) - Method in class org.apache.kafka.streams.kstream.TimeWindows
 
until(long) - Method in class org.apache.kafka.streams.kstream.UnlimitedWindows
Throws an IllegalArgumentException because the retention time for unlimited windows is always infinite and cannot be changed.
until(long) - Method in class org.apache.kafka.streams.kstream.Windows
Set the window maintain duration (retention time) in milliseconds.
updateSubscriptions(StreamPartitionAssignor.SubscriptionUpdates, String) - Method in class org.apache.kafka.streams.processor.TopologyBuilder
Deprecated.
NOTE this function would not needed by developers working with the processor APIs, but only used for the high-level DSL parsing functionalities.
UPGRADE_FROM_0100 - Static variable in class org.apache.kafka.streams.StreamsConfig
Config value for parameter "upgrade.from" for upgrading an application from version 0.10.0.x.
UPGRADE_FROM_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
upgrade.from
UPGRADE_FROM_DOC - Static variable in class org.apache.kafka.streams.StreamsConfig
 
UsePreviousTimeOnInvalidTimestamp - Class in org.apache.kafka.streams.processor
Retrieves embedded metadata timestamps from Kafka messages.
UsePreviousTimeOnInvalidTimestamp() - Constructor for class org.apache.kafka.streams.processor.UsePreviousTimeOnInvalidTimestamp
 

V

value - Variable in class org.apache.kafka.streams.KeyValue
The value of the key-value pair.
VALUE_SERDE_CLASS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
valueDeserializer() - Method in class org.apache.kafka.streams.state.StateSerdes
Return the value deserializer.
valueFrom(byte[]) - Method in class org.apache.kafka.streams.state.StateSerdes
Deserialize the value from raw bytes.
ValueJoiner<V1,V2,VR> - Interface in org.apache.kafka.streams.kstream
The ValueJoiner interface for joining two values into a new value of arbitrary type.
ValueMapper<V,VR> - Interface in org.apache.kafka.streams.kstream
The ValueMapper interface for mapping a value to a new value of arbitrary type.
ValueMapperWithKey<K,V,VR> - Interface in org.apache.kafka.streams.kstream
The ValueMapperWithKey interface for mapping a value to a new value of arbitrary type.
valueOf(String) - Static method in enum org.apache.kafka.streams.errors.DeserializationExceptionHandler.DeserializationHandlerResponse
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.kafka.streams.errors.ProductionExceptionHandler.ProductionExceptionHandlerResponse
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.kafka.streams.KafkaStreams.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.kafka.streams.processor.PunctuationType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.kafka.streams.processor.TopologyBuilder.AutoOffsetReset
Deprecated.
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.kafka.streams.Topology.AutoOffsetReset
Returns the enum constant of this type with the specified name.
values() - Static method in enum org.apache.kafka.streams.errors.DeserializationExceptionHandler.DeserializationHandlerResponse
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.kafka.streams.errors.ProductionExceptionHandler.ProductionExceptionHandlerResponse
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.kafka.streams.KafkaStreams.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.kafka.streams.processor.PunctuationType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.kafka.streams.processor.TopologyBuilder.AutoOffsetReset
Deprecated.
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.kafka.streams.Topology.AutoOffsetReset
Returns an array containing the constants of this enum type, in the order they are declared.
valueSerde - Variable in class org.apache.kafka.streams.Consumed
 
valueSerde(Serde<V>) - Static method in class org.apache.kafka.streams.kstream.Joined
Create an instance of Joined with a value Serde.
valueSerde() - Method in class org.apache.kafka.streams.kstream.Joined
 
valueSerde - Variable in class org.apache.kafka.streams.kstream.Materialized
 
valueSerde - Variable in class org.apache.kafka.streams.kstream.Produced
 
valueSerde(Serde<V>) - Static method in class org.apache.kafka.streams.kstream.Produced
Create a Produced instance with provided valueSerde.
valueSerde - Variable in class org.apache.kafka.streams.kstream.Serialized
 
valueSerde() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
Returns the default value serde
valueSerde() - Method in class org.apache.kafka.streams.state.StateSerdes
Return the value serde.
valueSerde() - Method in class org.apache.kafka.streams.StreamsConfig
Deprecated.
valueSerializer() - Method in class org.apache.kafka.streams.state.StateSerdes
Return the value serializer.
ValueTransformer<V,VR> - Interface in org.apache.kafka.streams.kstream
The ValueTransformer interface for stateful mapping of a value to a new value (with possible new type).
ValueTransformerSupplier<V,VR> - Interface in org.apache.kafka.streams.kstream
A ValueTransformerSupplier interface which can create one or more ValueTransformer instances.
ValueTransformerWithKey<K,V,VR> - Interface in org.apache.kafka.streams.kstream
The ValueTransformerWithKey interface for stateful mapping of a value to a new value (with possible new type).
ValueTransformerWithKeySupplier<K,V,VR> - Interface in org.apache.kafka.streams.kstream
 

W

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 - Class in org.apache.kafka.streams.kstream
A single window instance, defined by its start and end timestamp.
Window(long, long) - Constructor for class org.apache.kafka.streams.kstream.Window
Create a new window for the given start and end time.
window() - Method in class org.apache.kafka.streams.kstream.Windowed
Return the window containing the values associated with this key.
WINDOW_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 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(long, long, int, boolean) - Method in interface org.apache.kafka.streams.state.Stores.PersistentKeyValueFactory
Deprecated.
Set the persistent store as a windowed key-value store
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.
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.
Windows<W extends Window> - Class in org.apache.kafka.streams.kstream
The window specification interface for fixed size windows that is used to define window boundaries and window maintain duration.
Windows() - Constructor for class org.apache.kafka.streams.kstream.Windows
 
windowsFor(long) - Method in class org.apache.kafka.streams.kstream.JoinWindows
Not supported by JoinWindows.
windowsFor(long) - Method in class org.apache.kafka.streams.kstream.TimeWindows
 
windowsFor(long) - Method in class org.apache.kafka.streams.kstream.UnlimitedWindows
 
windowsFor(long) - Method in class org.apache.kafka.streams.kstream.Windows
Create all windows that contain the provided timestamp, indexed by non-negative window start timestamps.
windowSize() - Method in interface org.apache.kafka.streams.state.WindowBytesStoreSupplier
The size of the windows any store created from this supplier is creating.
windowStore() - Static method in class org.apache.kafka.streams.state.QueryableStoreTypes
WindowStore<K,V> - Interface in org.apache.kafka.streams.state
A windowed store interface extending StateStore.
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 a WindowStore.
WindowStoreIterator<V> - Interface in org.apache.kafka.streams.state
Iterator interface of KeyValue with key typed Long used for ReadOnlyWindowStore.fetch(Object, long, long).
with(Serde<K>, Serde<V>, TimestampExtractor, Topology.AutoOffsetReset) - Static method in class org.apache.kafka.streams.Consumed
Create an instance of Consumed with the supplied arguments.
with(Serde<K>, Serde<V>) - Static method in class org.apache.kafka.streams.Consumed
Create an instance of Consumed with key and value Serdes.
with(TimestampExtractor) - Static method in class org.apache.kafka.streams.Consumed
Create an instance of Consumed with a TimestampExtractor.
with(Topology.AutoOffsetReset) - Static method in class org.apache.kafka.streams.Consumed
Create an instance of Consumed with a Topology.AutoOffsetReset.
with(Serde<K>, Serde<V>, Serde<VO>) - Static method in class org.apache.kafka.streams.kstream.Joined
Create an instance of Joined with key, value, and otherValue Serde instances.
with(Serde<K>, Serde<V>) - Static method in class org.apache.kafka.streams.kstream.Materialized
Materialize a StateStore with the provided key and value Serdes.
with(Serde<K>, Serde<V>) - Static method in class org.apache.kafka.streams.kstream.Produced
Create a Produced instance with provided keySerde and valueSerde.
with(Serde<K>, Serde<V>, StreamPartitioner<? super K, ? super V>) - Static method in class org.apache.kafka.streams.kstream.Produced
Create a Produced instance with provided keySerde, valueSerde, and partitioner.
with(Serde<K>, Serde<V>) - Static method in class org.apache.kafka.streams.kstream.Serialized
Construct a Serialized instance with the provided key and value Serdes.
with(long) - Static method in class org.apache.kafka.streams.kstream.SessionWindows
Create a new window specification with the specified inactivity gap in milliseconds.
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.
withByteArrayKeys() - Method in class org.apache.kafka.streams.state.Stores.StoreFactory
Begin to create a KeyValueStore by specifying the keys will be byte arrays.
withByteArrayValues() - Method in class org.apache.kafka.streams.state.Stores.ValueFactory
Use byte arrays for values.
withByteBufferKeys() - Method in class org.apache.kafka.streams.state.Stores.StoreFactory
Begin to create a KeyValueStore by specifying the keys will be ByteBuffer.
withByteBufferValues() - Method in class org.apache.kafka.streams.state.Stores.ValueFactory
Use ByteBuffer for values.
withCachingDisabled() - Method in class org.apache.kafka.streams.kstream.Materialized
Disable caching for the materialized StateStore.
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.
withDoubleKeys() - Method in class org.apache.kafka.streams.state.Stores.StoreFactory
Begin to create a KeyValueStore by specifying the keys will be Doubles.
withDoubleValues() - Method in class org.apache.kafka.streams.state.Stores.ValueFactory
Use Double values.
withIntegerKeys() - Method in class org.apache.kafka.streams.state.Stores.StoreFactory
Begin to create a KeyValueStore by specifying the keys will be Integers.
withIntegerValues() - Method in class org.apache.kafka.streams.state.Stores.ValueFactory
Use Integer values.
withKeys(Class<K>) - Method in class org.apache.kafka.streams.state.Stores.StoreFactory
Begin to create a KeyValueStore by specifying the keys.
withKeys(Serde<K>) - Method in class org.apache.kafka.streams.state.Stores.StoreFactory
Begin to create a KeyValueStore by specifying the serializer and deserializer for the keys.
withKeySerde(Serde<K>) - Method in class org.apache.kafka.streams.Consumed
Configure the instance of Consumed with a key Serde.
withKeySerde(Serde<K>) - Method in class org.apache.kafka.streams.kstream.Joined
Set the key Serde to be used.
withKeySerde(Serde<K>) - Method in class org.apache.kafka.streams.kstream.Materialized
Set the keySerde the materialize StateStore will use.
withKeySerde(Serde<K>) - Method in class org.apache.kafka.streams.kstream.Produced
Produce records using the provided keySerde.
withKeySerde(Serde<K>) - Method in class org.apache.kafka.streams.kstream.Serialized
Construct a Serialized instance with the provided key Serde.
withKeyValueMapper(KeyValueMapper<? super K, ? super V, String>) - Method in class org.apache.kafka.streams.kstream.Printed
Print the records of a KStream with the provided KeyValueMapper The provided KeyValueMapper's mapped value type must be String.
withLabel(String) - Method in class org.apache.kafka.streams.kstream.Printed
Print the records of a KStream with the provided label.
withLoggingDisabled() - Method in class org.apache.kafka.streams.kstream.Materialized
Disable change logging for the materialized StateStore.
withLoggingDisabled() - Method in 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 interface org.apache.kafka.streams.state.StoreBuilder
Maintain a changelog for any changes made to the store.
withLongKeys() - Method in class org.apache.kafka.streams.state.Stores.StoreFactory
Begin to create a KeyValueStore by specifying the keys will be Longs.
withLongValues() - Method in class org.apache.kafka.streams.state.Stores.ValueFactory
Use Long values.
withOffsetResetPolicy(Topology.AutoOffsetReset) - Method in class org.apache.kafka.streams.Consumed
Configure the instance of Consumed with a Topology.AutoOffsetReset.
withOtherValueSerde(Serde<VO>) - Method in class org.apache.kafka.streams.kstream.Joined
Set the otherValue Serde to be used.
withStreamPartitioner(StreamPartitioner<? super K, ? super V>) - Method in class org.apache.kafka.streams.kstream.Produced
Produce records using the provided partitioner.
withStringKeys() - Method in class org.apache.kafka.streams.state.Stores.StoreFactory
Begin to create a KeyValueStore by specifying the keys will be Strings.
withStringValues() - Method in class org.apache.kafka.streams.state.Stores.ValueFactory
Use String values.
withTimestampExtractor(TimestampExtractor) - Method in class org.apache.kafka.streams.Consumed
Configure the instance of Consumed with a TimestampExtractor.
withValues(Class<V>) - Method in class org.apache.kafka.streams.state.Stores.ValueFactory
Use values of the specified type.
withValues(Serde<V>) - Method in class org.apache.kafka.streams.state.Stores.ValueFactory
Use the specified serializer and deserializer for the values.
withValueSerde(Serde<V>) - Method in class org.apache.kafka.streams.Consumed
Configure the instance of Consumed with a value Serde.
withValueSerde(Serde<V>) - Method in class org.apache.kafka.streams.kstream.Joined
Set the value Serde to be used.
withValueSerde(Serde<V>) - Method in class org.apache.kafka.streams.kstream.Materialized
Set the valueSerde the materialized StateStore will use.
withValueSerde(Serde<V>) - Method in class org.apache.kafka.streams.kstream.Produced
Produce records using the provided valueSerde.
withValueSerde(Serde<V>) - Method in class org.apache.kafka.streams.kstream.Serialized
Construct a Serialized instance with the provided value Serde.
writeAsText(String) - Method in interface org.apache.kafka.streams.kstream.KStream
writeAsText(String, String) - Method in interface org.apache.kafka.streams.kstream.KStream
writeAsText(String, Serde<K>, Serde<V>) - Method in interface org.apache.kafka.streams.kstream.KStream
writeAsText(String, String, Serde<K>, Serde<V>) - Method in interface org.apache.kafka.streams.kstream.KStream
writeAsText(String, KeyValueMapper<? super K, ? super V, String>) - Method in interface org.apache.kafka.streams.kstream.KStream
writeAsText(String, String, KeyValueMapper<? super K, ? super V, String>) - Method in interface org.apache.kafka.streams.kstream.KStream
writeAsText(String, Serde<K>, Serde<V>, KeyValueMapper<? super K, ? super V, String>) - Method in interface org.apache.kafka.streams.kstream.KStream
writeAsText(String, String, Serde<K>, Serde<V>, KeyValueMapper<? super K, ? super V, String>) - Method in interface org.apache.kafka.streams.kstream.KStream
writeAsText(String) - Method in interface org.apache.kafka.streams.kstream.KTable
Deprecated.
Use the Interactive Queries APIs (e.g., KafkaStreams.store(String, QueryableStoreType) followed by ReadOnlyKeyValueStore.all()) to iterate over the keys of a KTable. Alternatively convert to a KStream using KTable.toStream() and then use print(Printed.toFile(filePath) on the result.
writeAsText(String, String) - Method in interface org.apache.kafka.streams.kstream.KTable
Deprecated.
Use the Interactive Queries APIs (e.g., KafkaStreams.store(String, QueryableStoreType) followed by ReadOnlyKeyValueStore.all()) to iterate over the keys of a KTable. Alternatively convert to a KStream using KTable.toStream() and then use print(Printed.toFile(filePath).withLabel(label) on the result.
writeAsText(String, Serde<K>, Serde<V>) - Method in interface org.apache.kafka.streams.kstream.KTable
Deprecated.
Use the Interactive Queries APIs (e.g., KafkaStreams.store(String, QueryableStoreType) followed by ReadOnlyKeyValueStore.all()) to iterate over the keys of a KTable. Alternatively convert to a KStream using KTable.toStream() and then use print(Printed.toFile(filePath).withKeyValueMapper(...) on the result.
writeAsText(String, String, Serde<K>, Serde<V>) - Method in interface org.apache.kafka.streams.kstream.KTable
Deprecated.
Use the Interactive Queries APIs (e.g., KafkaStreams.store(String, QueryableStoreType) followed by ReadOnlyKeyValueStore.all()) to iterate over the keys of a KTable. Alternatively convert to a KStream using KTable.toStream() and then use print(Printed.toFile(filePath).withLabel(label).withKeyValueMapper(...) on the result.
writeTo(DataOutputStream) - Method in class org.apache.kafka.streams.processor.TaskId
 
writeTo(ByteBuffer) - Method in class org.apache.kafka.streams.processor.TaskId
 

Z

ZOOKEEPER_CONNECT_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
Deprecated.
Kakfa Streams does not use Zookeeper anymore and this parameter will be ignored.
A B C D E F G H I J K L M N O P Q R S T U V W Z