Package org.apache.kafka.streams.processor
package org.apache.kafka.streams.processor
Provides a low-level programming model (Processor API, aka, PAPI) to express a (stateful) data flow computation over input topics.
Use
Topology
as the entry point for your program.-
ClassDescriptionInterface for batching restoration of a
StateStore
It is expected that implementations of this class will not call theStateRestoreCallback.restore(byte[], byte[])
method.Cancellable interface returned inProcessingContext.schedule(Duration, PunctuationType, Punctuator)
.Stores can register this callback to be notified upon successful commit.Provides a set ofStoreBuilder
s that will be automatically added to the topology and connected to the associated processor.Retrieves embedded metadata timestamps from Kafka messages.Retrieves embedded metadata timestamps from Kafka messages.Deprecated.Since 4.0.MockProcessorContext.CapturedPunctuator
holds captured punctuators, along with their scheduling information.Processor context interface.Controls what notion of time is used for punctuation scheduled viaschedule
: STREAM_TIME - uses "stream time", which is advanced by the processing of messages in accordance with the timestamp as extracted by theTimestampExtractor
in use.A functional interface used as an argument toProcessorContext.schedule(Duration, PunctuationType, Punctuator)
.The context associated with the current record being processed by aProcessor
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.Class for listening to various states of the restoration process of a StateStore.A storage engine for managing state maintained by a stream processor.State store context interface.StreamPartitioner<K,V> Determine how records are distributed among the partitions in a Kafka topic.The task ID representation composed as subtopology plus the assigned partition ID.An interface that allows the Kafka Streams framework to extract a timestamp from an instance ofConsumerRecord
.This class is used to provide the optional parameters when sending output records to downstream processor usingProcessorContext.forward(Object, Object, To)
.TopicNameExtractor<K,V> An interface that allows to dynamically determine the name of the Kafka topic to send at the sink node of the topology.Retrieves embedded metadata timestamps from Kafka messages.Retrieves current wall clock timestamps asSystem.currentTimeMillis()
.