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

A

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
 
addInternalTopic(String) - Method in class org.apache.kafka.streams.processor.TopologyBuilder
Adds an internal topic
addLatencySensor(String, String, String, String...) - Method in interface org.apache.kafka.streams.StreamsMetrics
 
addProcessor(String, ProcessorSupplier, String...) - Method in class org.apache.kafka.streams.processor.TopologyBuilder
Add a new processor node that receives and processes messages output by one or more parent source or processor node.
addSink(String, String, String...) - Method in class org.apache.kafka.streams.processor.TopologyBuilder
Add a new sink that forwards messages from upstream parent processor and/or source nodes to the named Kafka topic.
addSink(String, String, StreamPartitioner, String...) - Method in class org.apache.kafka.streams.processor.TopologyBuilder
Add a new sink that forwards messages from upstream parent processor and/or source nodes to the named Kafka topic, using the supplied partitioner.
addSink(String, String, Serializer, Serializer, String...) - Method in class org.apache.kafka.streams.processor.TopologyBuilder
Add a new sink that forwards messages from upstream parent processor and/or source nodes to the named Kafka topic.
addSink(String, String, Serializer<K>, Serializer<V>, StreamPartitioner<K, V>, String...) - Method in class org.apache.kafka.streams.processor.TopologyBuilder
Add a new sink that forwards messages 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
Add a new source that consumes the named topics and forwards the messages to child processor and/or sink nodes.
addSource(String, Deserializer, Deserializer, String...) - Method in class org.apache.kafka.streams.processor.TopologyBuilder
Add a new source that consumes the named topics and forwards the messages to child processor and/or sink nodes.
addStateStore(StateStoreSupplier, boolean, String...) - Method in class org.apache.kafka.streams.processor.TopologyBuilder
Adds a state store
addStateStore(StateStoreSupplier, String...) - Method in class org.apache.kafka.streams.processor.TopologyBuilder
Adds a state store
after - Variable in class org.apache.kafka.streams.kstream.JoinWindows
 
after(long) - Method in class org.apache.kafka.streams.kstream.JoinWindows
Specifies that records of the same key are joinable if their timestamp stamps are within timeDifference, and if the timestamp of a record from the secondary stream is is later than or equal to the timestamp of a record from the first stream.
aggregate(Initializer<T>, Aggregator<K1, V1, T>, Aggregator<K1, V1, T>, KeyValueMapper<K, V, KeyValue<K1, V1>>, Serializer<K1>, Serializer<V1>, Serializer<T>, Deserializer<K1>, Deserializer<V1>, Deserializer<T>, String) - Method in interface org.apache.kafka.streams.kstream.KTable
Aggregate values of this table by the selected key.
aggregateByKey(Initializer<T>, Aggregator<K, V, T>, Windows<W>, Serializer<K>, Serializer<T>, Deserializer<K>, Deserializer<T>) - Method in interface org.apache.kafka.streams.kstream.KStream
Aggregate values of this stream by key on a window basis.
aggregateByKey(Initializer<T>, Aggregator<K, V, T>, Serializer<K>, Serializer<T>, Deserializer<K>, Deserializer<T>, String) - Method in interface org.apache.kafka.streams.kstream.KStream
Aggregate values of this stream by key without a window basis, and hence return an ever updating table
Aggregator<K,V,T> - 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.KeyValueStore
Return an iterator over all keys in the database.
apply(K, V, T) - Method in interface org.apache.kafka.streams.kstream.Aggregator
 
apply() - Method in interface org.apache.kafka.streams.kstream.Initializer
 
apply(K, V) - Method in interface org.apache.kafka.streams.kstream.KeyValueMapper
 
apply(V, V) - Method in interface org.apache.kafka.streams.kstream.Reducer
 
apply(V1, V2) - Method in interface org.apache.kafka.streams.kstream.ValueJoiner
 
apply(V1) - Method in interface org.apache.kafka.streams.kstream.ValueMapper
 
AUTO_OFFSET_RESET_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
auto.offset.reset

B

before - Variable in class org.apache.kafka.streams.kstream.JoinWindows
 
before(long) - Method in class org.apache.kafka.streams.kstream.JoinWindows
Specifies that records of the same key are joinable if their timestamp stamps are within timeDifference, and if the timestamp of a record from the secondary stream is is earlier than or equal to the timestamp of a record from the first stream.
BOOTSTRAP_SERVERS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
bootstrap.servers
branch(Predicate<K, V>...) - Method in interface org.apache.kafka.streams.kstream.KStream
Creates an array of streams from this stream.
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
Build the topology for the specified topic group.
build() - Method in interface org.apache.kafka.streams.state.Stores.InMemoryKeyValueFactory
Return the instance of StateStoreSupplier of new key-value store.
build() - Method in interface org.apache.kafka.streams.state.Stores.PersistentKeyValueFactory
Return the instance of StateStoreSupplier of new key-value store.

C

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 stream instance by signaling all the threads to stop, and then wait for them 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 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
 
connectProcessorAndStateStores(String, String...) - Method in class org.apache.kafka.streams.processor.TopologyBuilder
Connects the processor and the state stores
connectProcessors(String...) - Method in class org.apache.kafka.streams.processor.TopologyBuilder
Connects a list of processors.
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
Returns the copartition groups.
copartitionSources(Collection<String>) - Method in class org.apache.kafka.streams.processor.TopologyBuilder
Asserts that the streams of the specified source nodes must be copartitioned.
count(KeyValueMapper<K, V, K1>, Serializer<K1>, Serializer<V>, Serializer<Long>, Deserializer<K1>, Deserializer<V>, Deserializer<Long>, String) - Method in interface org.apache.kafka.streams.kstream.KTable
Count number of records of this table by the selected key.
countByKey(Windows<W>, Serializer<K>, Serializer<Long>, Deserializer<K>, Deserializer<Long>) - Method in interface org.apache.kafka.streams.kstream.KStream
Count number of messages of this stream by key on a window basis.
countByKey(Serializer<K>, Serializer<Long>, Deserializer<K>, Deserializer<Long>, String) - Method in interface org.apache.kafka.streams.kstream.KStream
Count number of messages of this stream by key without a window basis, and hence return a ever updating counting table
create(String) - Static method in class org.apache.kafka.streams.state.Stores
Begin to create a new StateStoreSupplier instance.

D

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
 
delete(K) - Method in interface org.apache.kafka.streams.state.KeyValueStore
Delete the value from the store (if there is one)

E

emit(long) - Method in class org.apache.kafka.streams.kstream.Windows
Set the window emit duration in milliseconds of system time
emitEveryMs() - Method in class org.apache.kafka.streams.kstream.Windows
 
end() - Method in class org.apache.kafka.streams.kstream.Window
Returns the end timestamp of this window, exclusive
equals(Object) - Method in class org.apache.kafka.streams.KeyValue
 
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.TopologyBuilder.TopicsInfo
 
equalsTo(Window) - Method in class org.apache.kafka.streams.kstream.Window
 
equalTo(Windows) - Method in class org.apache.kafka.streams.kstream.HoppingWindows
 
equalTo(Windows) - Method in class org.apache.kafka.streams.kstream.JoinWindows
 
equalTo(Windows) - Method in class org.apache.kafka.streams.kstream.TumblingWindows
 
equalTo(Windows) - Method in class org.apache.kafka.streams.kstream.UnlimitedWindows
 
equalTo(Windows) - Method in class org.apache.kafka.streams.kstream.Windows
 
every(long) - Method in class org.apache.kafka.streams.kstream.HoppingWindows
Returns a new hopping window definition with the original size but reassign the window period in milliseconds of the form [ N * period, N * period + size )
extract(ConsumerRecord<Object, Object>) - Method in interface org.apache.kafka.streams.processor.TimestampExtractor
Extracts a timestamp from a message

F

fetch(K, long, long) - Method in interface org.apache.kafka.streams.state.WindowStore
Get all the key-value pairs with the given key and the time range from all the existing windows.
filter(Predicate<K, V>) - Method in interface org.apache.kafka.streams.kstream.KStream
Creates a new instance of KStream consists of all elements of this stream which satisfy a predicate
filter(Predicate<K, V>) - Method in interface org.apache.kafka.streams.kstream.KTable
Creates a new instance of KTable consists of all elements of this stream which satisfy a predicate
filterOut(Predicate<K, V>) - Method in interface org.apache.kafka.streams.kstream.KStream
Creates a new instance of KStream consists all elements of this stream which do not satisfy a predicate
filterOut(Predicate<K, V>) - Method in interface org.apache.kafka.streams.kstream.KTable
Creates a new instance of KTable consists all elements of this stream which do not satisfy a predicate
flatMap(KeyValueMapper<K, V, Iterable<KeyValue<K1, V1>>>) - Method in interface org.apache.kafka.streams.kstream.KStream
Creates a new instance of KStream by transforming each element in this stream into zero or more elements in the new stream.
flatMapValues(ValueMapper<V, Iterable<V1>>) - Method in interface org.apache.kafka.streams.kstream.KStream
Creates a new stream by transforming each value in this stream into zero or more values in the new stream.
flush() - Method in interface org.apache.kafka.streams.processor.StateStore
Flush any cached data
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

G

get() - Method in interface org.apache.kafka.streams.kstream.TransformerSupplier
 
get() - Method in interface org.apache.kafka.streams.kstream.ValueTransformerSupplier
 
get() - Method in interface org.apache.kafka.streams.processor.ProcessorSupplier
 
get() - Method in interface org.apache.kafka.streams.processor.StateStoreSupplier
 
get(K) - Method in interface org.apache.kafka.streams.state.KeyValueStore
Get the value corresponding to this key
getConsumerConfigs(StreamThread, String, String) - Method in class org.apache.kafka.streams.StreamsConfig
 
getProducerConfigs(String) - Method in class org.apache.kafka.streams.StreamsConfig
 
getRestoreConsumerConfigs(String) - Method in class org.apache.kafka.streams.StreamsConfig
 
getStateStore(String) - Method in interface org.apache.kafka.streams.processor.ProcessorContext
Get the state store given the store name.

H

hashCode() - Method in class org.apache.kafka.streams.KeyValue
 
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.TopologyBuilder.TopicsInfo
 
HoppingWindows - Class in org.apache.kafka.streams.kstream
The hopping window specifications used for aggregations.

I

init(ProcessorContext) - Method in interface org.apache.kafka.streams.kstream.Transformer
Initialize this transformer with the given context.
init(ProcessorContext) - Method in interface org.apache.kafka.streams.kstream.ValueTransformer
Initialize this transformer with the given context.
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<T> - Interface in org.apache.kafka.streams.kstream
The Initializer interface for creating an initial value for 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.
INNER_SERDES - Static variable in class org.apache.kafka.streams.state.WindowStoreUtils
 
interSourceTopics - Variable in class org.apache.kafka.streams.processor.TopologyBuilder.TopicsInfo
 

J

JOB_ID_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
job.id
JOB_ID_DOC - Static variable in class org.apache.kafka.streams.StreamsConfig
 
jobId() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
Returns the job id
join(KStream<K, V1>, ValueJoiner<V, V1, R>, JoinWindows, Serializer<K>, Serializer<V>, Serializer<V1>, Deserializer<K>, Deserializer<V>, Deserializer<V1>) - Method in interface org.apache.kafka.streams.kstream.KStream
Combines values of this stream with another KStream using Windowed Inner Join.
join(KTable<K, V1>, ValueJoiner<V, V1, R>) - Method in interface org.apache.kafka.streams.kstream.KTable
Combines values of this KTable with another KTable using Inner Join.
JoinWindows - Class in org.apache.kafka.streams.kstream
The window specifications used for joins.

K

KafkaStreams - Class in org.apache.kafka.streams
Kafka Streams allows for performing continuous computation on input coming from one or more input topics and sends output to zero 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
Construct the stream instance.
key - Variable in class org.apache.kafka.streams.KeyValue
 
KEY_DESERIALIZER_CLASS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
key.deserializer
KEY_SERIALIZER_CLASS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
key.serializer
keyDeserializer() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
Returns the key deserializer
keyDeserializer() - Method in class org.apache.kafka.streams.state.Serdes
 
keyDeserializer() - Method in class org.apache.kafka.streams.StreamsConfig
 
keyFrom(byte[]) - Method in class org.apache.kafka.streams.state.Serdes
 
keyFromBinaryKey(byte[], Serdes<K, ?>) - Static method in class org.apache.kafka.streams.state.WindowStoreUtils
 
keySerializer() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
Returns the key serializer
keySerializer() - Method in class org.apache.kafka.streams.state.Serdes
 
keySerializer() - Method in class org.apache.kafka.streams.StreamsConfig
 
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
 
KeyValueIterator<K,V> - Interface in org.apache.kafka.streams.state
Iterator interface of KeyValue.
KeyValueMapper<K,V,R> - Interface in org.apache.kafka.streams.kstream
The KeyValueMapper interface for mapping a key-value pair to a new value (could be another key-value pair).
KeyValueStore<K,V> - Interface in org.apache.kafka.streams.state
A key-value store that supports put/get/delete and range queries.
KStream<K,V> - Interface in org.apache.kafka.streams.kstream
KStream is an abstraction of an event stream in key-value pairs.
KStreamBuilder - Class in org.apache.kafka.streams.kstream
KStreamBuilder is a subclass of TopologyBuilder that provides the KStream DSL for users to specify computational logic and translates the given logic to a processor topology.
KStreamBuilder() - Constructor for class org.apache.kafka.streams.kstream.KStreamBuilder
 
KTable<K,V> - Interface in org.apache.kafka.streams.kstream
KTable is an abstraction of a change log stream from a primary-keyed table.

L

leftJoin(KStream<K, V1>, ValueJoiner<V, V1, R>, JoinWindows, Serializer<K>, Serializer<V1>, Deserializer<K>, Deserializer<V1>) - Method in interface org.apache.kafka.streams.kstream.KStream
Combines values of this stream with another KStream using Windowed Left Join.
leftJoin(KTable<K, V1>, ValueJoiner<V, V1, V2>) - Method in interface org.apache.kafka.streams.kstream.KStream
Combines values of this stream with KTable using Left Join.
leftJoin(KTable<K, V1>, ValueJoiner<V, V1, R>) - Method in interface org.apache.kafka.streams.kstream.KTable
Combines values of this KTable with another KTable using Left Join.

M

main(String[]) - Static method in class org.apache.kafka.streams.StreamsConfig
 
maintainMs() - Method in class org.apache.kafka.streams.kstream.Windows
 
map(KeyValueMapper<K, V, KeyValue<K1, V1>>) - Method in interface org.apache.kafka.streams.kstream.KStream
Creates a new instance of KStream by applying transforming each element in this stream into a different element in the new stream.
mapValues(ValueMapper<V, V1>) - Method in interface org.apache.kafka.streams.kstream.KStream
Creates a new instance of KStream by transforming each value in this stream into a different value in the new stream.
mapValues(ValueMapper<V, V1>) - Method in interface org.apache.kafka.streams.kstream.KTable
Creates a new instance of KTable by transforming each value in this stream into a different value in the new stream.
maxEntries(int) - Method in interface org.apache.kafka.streams.state.Stores.InMemoryKeyValueFactory
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 class org.apache.kafka.streams.kstream.KStreamBuilder
Creates a new stream by merging the given streams
METRIC_REPORTER_CLASSES_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
metric.reporters
metrics() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
Returns Metrics instance
METRICS_NUM_SAMPLES_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
metrics.num.samples
METRICS_SAMPLE_WINDOW_MS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
metrics.sample.window.ms

N

name - Variable in class org.apache.kafka.streams.kstream.Windows
 
name() - Method in class org.apache.kafka.streams.kstream.Windows
 
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
 
newName(String) - Method in class org.apache.kafka.streams.kstream.KStreamBuilder
Create a unique processor name used for translation into the processor topology.
newName(String) - Method in class org.apache.kafka.streams.kstream.Windows
 
NO_ITERATORS - Static variable in class org.apache.kafka.streams.state.WindowStoreUtils
 
nodeGroups() - Method in class org.apache.kafka.streams.processor.TopologyBuilder
Returns the map of node groups keyed by the topic group id.
NUM_STANDBY_REPLICAS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
num.stream.threads
NUM_STREAM_THREADS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
num.stream.threads

O

of(String) - Static method in class org.apache.kafka.streams.kstream.HoppingWindows
Returns a half-interval hopping window definition with the window size in milliseconds of the form [ N * default_size, N * default_size + default_size )
of(String) - Static method in class org.apache.kafka.streams.kstream.JoinWindows
 
of(String) - Static method in class org.apache.kafka.streams.kstream.TumblingWindows
Returns a half-interval sliding window definition with the default window size
of(String) - Static method in class org.apache.kafka.streams.kstream.UnlimitedWindows
Returns an unlimited window definition
offset() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
Returns the offset of the current input record
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
 
outerJoin(KStream<K, V1>, ValueJoiner<V, V1, R>, JoinWindows, Serializer<K>, Serializer<V>, Serializer<V1>, Deserializer<K>, Deserializer<V>, Deserializer<V1>) - Method in interface org.apache.kafka.streams.kstream.KStream
Combines values of this stream with another KStream using Windowed Outer Join.
outerJoin(KTable<K, V1>, ValueJoiner<V, V1, R>) - Method in interface org.apache.kafka.streams.kstream.KTable
Combines values of this KTable with another KTable using Outer Join.
overlap(Window) - Method in class org.apache.kafka.streams.kstream.Window
 

P

pair(K, V) - Static method in class org.apache.kafka.streams.KeyValue
 
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
partition(K, V, int) - Method in interface org.apache.kafka.streams.processor.StreamPartitioner
Determine the partition number for a message with the given key and value and the current number of partitions.
partition - Variable in class org.apache.kafka.streams.processor.TaskId
 
PARTITION_GROUPER_CLASS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
partition.grouper
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.
period - Variable in class org.apache.kafka.streams.kstream.HoppingWindows
 
persistent() - Method in interface org.apache.kafka.streams.processor.StateStore
If the storage is persistent
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.
POLL_MS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
poll.ms
Predicate<K,V> - Interface in org.apache.kafka.streams.kstream
The Predicate interface represents a predicate (boolean-valued function) of a key-value pair.
process(ProcessorSupplier<K, V>, String...) - Method in interface org.apache.kafka.streams.kstream.KStream
Processes all elements in this stream by applying a processor.
process(K, V) - Method in interface org.apache.kafka.streams.processor.Processor
Process the message with the given key and value.
Processor<K,V> - Interface in org.apache.kafka.streams.processor
A processor of key-value pair records.
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.
punctuate(long) - Method in interface org.apache.kafka.streams.kstream.Transformer
Perform any periodic operations, if this processor schedule itself with the context during initialization.
punctuate(long) - Method in interface org.apache.kafka.streams.kstream.ValueTransformer
Perform any periodic operations, if this processor schedule itself with the context during initialization.
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
Perform any periodic operations, if this processor schedule itself with the context during initialization.
put(K, V) - Method in interface org.apache.kafka.streams.state.KeyValueStore
Update the value associated with this key
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

R

range(K, K) - Method in interface org.apache.kafka.streams.state.KeyValueStore
Get an iterator over a given range of keys.
rawKey(K) - Method in class org.apache.kafka.streams.state.Serdes
 
rawValue(V) - Method in class org.apache.kafka.streams.state.Serdes
 
readFrom(DataInputStream) - Static method in class org.apache.kafka.streams.processor.TaskId
 
readFrom(ByteBuffer) - Static method in class org.apache.kafka.streams.processor.TaskId
 
recordLatency(Sensor, long, long) - Method in interface org.apache.kafka.streams.StreamsMetrics
 
reduce(Reducer<V1>, Reducer<V1>, KeyValueMapper<K, V, KeyValue<K1, V1>>, Serializer<K1>, Serializer<V1>, Deserializer<K1>, Deserializer<V1>, String) - Method in interface org.apache.kafka.streams.kstream.KTable
Reduce values of this table by the selected key.
reduceByKey(Reducer<V>, Windows<W>, Serializer<K>, Serializer<V>, Deserializer<K>, Deserializer<V>) - Method in interface org.apache.kafka.streams.kstream.KStream
Aggregate values of this stream by key on a window basis.
reduceByKey(Reducer<V>, Serializer<K>, Serializer<V>, Deserializer<K>, Deserializer<V>, String) - Method in interface org.apache.kafka.streams.kstream.KStream
Aggregate values of this stream by key on a window basis.
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.
REPLICATION_FACTOR_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
replication.factor
REPLICATION_FACTOR_DOC - Static variable in class org.apache.kafka.streams.StreamsConfig
 
restore(byte[], byte[]) - Method in interface org.apache.kafka.streams.processor.StateRestoreCallback
 

S

schedule(long) - Method in interface org.apache.kafka.streams.processor.ProcessorContext
Schedules a periodic operation for processors.
segments - Variable in class org.apache.kafka.streams.kstream.Windows
 
segments(int) - Method in class org.apache.kafka.streams.kstream.Windows
Specifies the number of segments to be used for rolling the window store, this function is not exposed to users but can be called by developers that extend this JoinWindows specs
SEQNUM_SIZE - Static variable in class org.apache.kafka.streams.state.WindowStoreUtils
 
Serdes<K,V> - Class in org.apache.kafka.streams.state
Factory for creating serializers / deserializers for state stores in Kafka Streams.
Serdes(String, Serializer<K>, Deserializer<K>, Serializer<V>, Deserializer<V>) - Constructor for class org.apache.kafka.streams.state.Serdes
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.
setUncaughtExceptionHandler(Thread.UncaughtExceptionHandler) - Method in class org.apache.kafka.streams.KafkaStreams
Sets the handler invoked when a stream thread abruptly terminates due to an uncaught exception.
sinkTopics - Variable in class org.apache.kafka.streams.processor.TopologyBuilder.TopicsInfo
 
size - Variable in class org.apache.kafka.streams.kstream.HoppingWindows
 
size - Variable in class org.apache.kafka.streams.kstream.TumblingWindows
 
sourceTopics() - Method in class org.apache.kafka.streams.processor.TopologyBuilder
Get the names of topics that are to be consumed by the source nodes created by this builder.
sourceTopics - Variable in class org.apache.kafka.streams.processor.TopologyBuilder.TopicsInfo
 
start() - Method in class org.apache.kafka.streams.KafkaStreams
Start the stream instance by starting all its threads.
start - Variable in class org.apache.kafka.streams.kstream.UnlimitedWindows
 
start() - Method in class org.apache.kafka.streams.kstream.Window
Returns the start timestamp of this window, inclusive
startOn(long) - Method in class org.apache.kafka.streams.kstream.UnlimitedWindows
 
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
 
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.
StateStore - Interface in org.apache.kafka.streams.processor
A storage engine for managing state maintained by a stream processor.
StateStoreSupplier - Interface in org.apache.kafka.streams.processor
A state store supplier which can create one or more StateStore instances.
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.InMemoryKeyValueFactory<K,V> - Interface in org.apache.kafka.streams.state
The interface used to create in-memory key-value stores.
Stores.KeyValueFactory<K,V> - Interface in org.apache.kafka.streams.state
The interface used to specify the different kinds of key-value stores.
Stores.PersistentKeyValueFactory<K,V> - Interface in org.apache.kafka.streams.state
The interface used to create off-heap key-value stores that use a local database.
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
 
stream(String...) - Method in class org.apache.kafka.streams.kstream.KStreamBuilder
Creates a KStream instance for the specified topic.
stream(Deserializer<K>, Deserializer<V>, String...) - Method in class org.apache.kafka.streams.kstream.KStreamBuilder
Creates a KStream instance for the specified topic.
STREAM_THREAD_INSTANCE - Static variable in class org.apache.kafka.streams.StreamsConfig.InternalConfig
 
StreamPartitioner<K,V> - Interface in org.apache.kafka.streams.processor
Determine how messages are distributed among the partitions in a Kafka topic.
StreamsConfig - Class in org.apache.kafka.streams
Configuration for Kafka Streams.
StreamsConfig(Map<?, ?>) - Constructor for class org.apache.kafka.streams.StreamsConfig
 
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
 
StreamsMetrics - Interface in org.apache.kafka.streams
The Kafka Streams metrics interface for adding metric sensors and collecting metric values.

T

table(String) - Method in class org.apache.kafka.streams.kstream.KStreamBuilder
Creates a KTable instance for the specified topic.
table(Serializer<K>, Serializer<V>, Deserializer<K>, Deserializer<V>, String) - Method in class org.apache.kafka.streams.kstream.KStreamBuilder
Creates a KTable instance for the specified topic.
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
 
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
 
test(K, V) - Method in interface org.apache.kafka.streams.kstream.Predicate
 
through(String) - Method in interface org.apache.kafka.streams.kstream.KStream
Sends key-value to a topic, also creates a new instance of KStream from the topic.
through(String, Serializer<K>, Serializer<V>, Deserializer<K>, Deserializer<V>) - Method in interface org.apache.kafka.streams.kstream.KStream
Sends key-value to a topic, also creates a new instance of KStream from the topic.
through(String) - Method in interface org.apache.kafka.streams.kstream.KTable
Sends key-value to a topic, also creates a new instance of KTable from the topic.
through(String, Serializer<K>, Serializer<V>, Deserializer<K>, Deserializer<V>) - Method in interface org.apache.kafka.streams.kstream.KTable
Sends key-value to a topic, also creates a new instance of KTable from the topic.
timestamp() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
Returns the timestamp of the current input record.
TIMESTAMP_EXTRACTOR_CLASS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
timestamp.extractor
TIMESTAMP_SIZE - Static variable in class org.apache.kafka.streams.state.WindowStoreUtils
 
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.
timestampFromBinaryKey(byte[]) - Static method in class org.apache.kafka.streams.state.WindowStoreUtils
 
to(String) - Method in interface org.apache.kafka.streams.kstream.KStream
Sends key-value to a topic using default serializers specified in the config.
to(String, Serializer<K>, Serializer<V>) - Method in interface org.apache.kafka.streams.kstream.KStream
Sends key-value to a topic.
to(String) - Method in interface org.apache.kafka.streams.kstream.KTable
Sends key-value to a topic using default serializers specified in the config.
to(String, Serializer<K>, Serializer<V>) - Method in interface org.apache.kafka.streams.kstream.KTable
Sends key-value to a topic.
toBinaryKey(K, long, int, Serdes<K, ?>) - Static method in class org.apache.kafka.streams.state.WindowStoreUtils
 
topic() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
Returns the topic name of the current input record
topic() - Method in class org.apache.kafka.streams.state.Serdes
 
topicGroupId - Variable in class org.apache.kafka.streams.processor.TaskId
 
topicGroups() - Method in class org.apache.kafka.streams.processor.TopologyBuilder
Returns the map of topic groups keyed by the group id.
TopologyBuilder - Class in org.apache.kafka.streams.processor
A component that is used to build a ProcessorTopology.
TopologyBuilder() - Constructor for class org.apache.kafka.streams.processor.TopologyBuilder
Create a new builder.
TopologyBuilder.TopicsInfo - Class in org.apache.kafka.streams.processor
 
TopologyBuilder.TopicsInfo(Set<String>, Set<String>, Set<String>, Set<String>) - Constructor for class org.apache.kafka.streams.processor.TopologyBuilder.TopicsInfo
 
TopologyBuilderException - Exception in org.apache.kafka.streams.errors
Indicates a pre-run time error incurred while parsing the builder to construct the processor topology
TopologyBuilderException(String) - Constructor for exception org.apache.kafka.streams.errors.TopologyBuilderException
 
toStream() - Method in interface org.apache.kafka.streams.kstream.KTable
Creates a new instance of KStream from this KTable
toString() - Method in class org.apache.kafka.streams.KeyValue
 
toString() - Method in class org.apache.kafka.streams.kstream.Windowed
 
toString() - Method in class org.apache.kafka.streams.processor.TaskId
 
transform(TransformerSupplier<K, V, KeyValue<K1, V1>>, String...) - Method in interface org.apache.kafka.streams.kstream.KStream
Applies a stateful transformation to all elements in this stream.
transform(K, V) - Method in interface org.apache.kafka.streams.kstream.Transformer
Transform the message with the given key and value.
transform(V) - Method in interface org.apache.kafka.streams.kstream.ValueTransformer
Transform the message with the given key and value.
Transformer<K,V,R> - Interface in org.apache.kafka.streams.kstream
A stateful Transformer interface for transform a key-value pair into a new value.
TransformerSupplier<K,V,R> - Interface in org.apache.kafka.streams.kstream
A transformer supplier which can create one or more Transformer instances.
transformValues(ValueTransformerSupplier<V, R>, String...) - Method in interface org.apache.kafka.streams.kstream.KStream
Applies a stateful transformation to all values in this stream.
TumblingWindows - Class in org.apache.kafka.streams.kstream
The tumbling window specifications used for aggregations.

U

UnlimitedWindows - Class in org.apache.kafka.streams.kstream
The unlimited window specifications.
until(long) - Method in class org.apache.kafka.streams.kstream.Windows
Set the window maintain duration in milliseconds of system time

V

value - Variable in class org.apache.kafka.streams.KeyValue
 
value() - Method in class org.apache.kafka.streams.kstream.Windowed
 
VALUE_DESERIALIZER_CLASS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
value.deserializer
VALUE_SERIALIZER_CLASS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
value.serializer
valueDeserializer() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
Returns the value deserializer
valueDeserializer() - Method in class org.apache.kafka.streams.state.Serdes
 
valueDeserializer() - Method in class org.apache.kafka.streams.StreamsConfig
 
valueFrom(byte[]) - Method in class org.apache.kafka.streams.state.Serdes
 
ValueJoiner<V1,V2,R> - Interface in org.apache.kafka.streams.kstream
The ValueJoiner interface for joining two values and return a the joined new value.
ValueMapper<V1,V2> - Interface in org.apache.kafka.streams.kstream
The KeyValueMapper interface for mapping an original value to a new value (could be another key-value pair).
valueSerializer() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
Returns the value serializer
valueSerializer() - Method in class org.apache.kafka.streams.state.Serdes
 
valueSerializer() - Method in class org.apache.kafka.streams.StreamsConfig
 
ValueTransformer<V,R> - Interface in org.apache.kafka.streams.kstream
A stateful Value Transformer interface for transform a value into a new value.
ValueTransformerSupplier<V,R> - Interface in org.apache.kafka.streams.kstream
A value transformer supplier which can create one or more ValueTransformer instances.

W

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
 
window() - Method in class org.apache.kafka.streams.kstream.Windowed
 
Windowed<T> - Class in org.apache.kafka.streams.kstream
The windowed key interface used in KTable, used for representing a windowed table result from windowed stream aggregations, i.e.
Windowed(T, Window) - Constructor for class org.apache.kafka.streams.kstream.Windowed
 
windowed(long, int, boolean) - Method in interface org.apache.kafka.streams.state.Stores.PersistentKeyValueFactory
Set the persistent store as a windowed key-value store
Windows<W extends Window> - Class in org.apache.kafka.streams.kstream
The window specification interface that can be extended for windowing operation in joins and aggregations.
Windows(String) - Constructor for class org.apache.kafka.streams.kstream.Windows
 
windowsFor(long) - Method in class org.apache.kafka.streams.kstream.HoppingWindows
 
windowsFor(long) - Method in class org.apache.kafka.streams.kstream.JoinWindows
 
windowsFor(long) - Method in class org.apache.kafka.streams.kstream.TumblingWindows
 
windowsFor(long) - Method in class org.apache.kafka.streams.kstream.UnlimitedWindows
 
windowsFor(long) - Method in class org.apache.kafka.streams.kstream.Windows
 
WindowStore<K,V> - Interface in org.apache.kafka.streams.state
A windowed store interface extending StateStore
WindowStoreIterator<E> - Interface in org.apache.kafka.streams.state
Iterator interface of KeyValue with key typed Long used for WindowStore.fetch(Object, long, long).
WindowStoreUtils - Class in org.apache.kafka.streams.state
 
WindowStoreUtils() - Constructor for class org.apache.kafka.streams.state.WindowStoreUtils
 
with(long) - Method in class org.apache.kafka.streams.kstream.HoppingWindows
Returns a new hopping window definition with the original size but reassign the window period in milliseconds of the form [ N * period, N * period + size )
with(long) - Method in class org.apache.kafka.streams.kstream.TumblingWindows
Returns a half-interval sliding window definition with the window size in milliseconds
withBuiltinTypes(String, Class<K>, Class<V>) - Static method in class org.apache.kafka.streams.state.Serdes
 
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.
within(long) - Method in class org.apache.kafka.streams.kstream.JoinWindows
Specifies that records of the same key are joinable if their timestamp stamps are within timeDifference.
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 will be either String, Integer, Long, or byte[].
withKeys(Serializer<K>, Deserializer<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.
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.
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.
withValues(Class<V>) - Method in class org.apache.kafka.streams.state.Stores.ValueFactory
Use values of the specified type, which must be either String, Integer, Long, or byte[] .
withValues(Serializer<V>, Deserializer<V>) - Method in class org.apache.kafka.streams.state.Stores.ValueFactory
Use the specified serializer and deserializer for the values.
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
zookeeper.connect
A B C D E F G H I J K L M N O P R S T U V W Z