Package org.apache.kafka.streams.processor
- 
Interface Summary Interface Description BatchingStateRestoreCallback Interface for batching restoration of aStateStoreIt is expected that implementations of this class will not call theStateRestoreCallback.restore(byte[], byte[])method.Cancellable Cancellable interface returned inProcessorContext.schedule(Duration, PunctuationType, Punctuator).ConnectedStoreProvider Provides a set ofStoreBuilders that will be automatically added to the topology and connected to the associated processor.PartitionGrouper Deprecated. since 2.4 release; will be removed in 3.0.0 via KAFKA-7785Processor<K,V> A processor of key-value pair records.ProcessorContext Processor context interface.ProcessorSupplier<K,V> A processor supplier that can create one or moreProcessorinstances.Punctuator A functional interface used as an argument toProcessorContext.schedule(Duration, PunctuationType, Punctuator).RecordContext The context associated with the current record being processed by anProcessorStateRestoreCallback 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 Class for listening to various states of the restoration process of a StateStore.StateStore A storage engine for managing state maintained by a stream processor.StateStoreContext State store context interface.StreamPartitioner<K,V> Determine how records are distributed among the partitions in a Kafka topic.TimestampExtractor An interface that allows the Kafka Streams framework to extract a timestamp from an instance ofConsumerRecord.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.
- 
Class Summary Class Description AbstractProcessor<K,V> An abstract implementation ofProcessorthat manages theProcessorContextinstance and provides default no-op implementation ofAbstractProcessor.close().DefaultPartitionGrouper Deprecated. since 2.4 release; will be removed in 3.0.0 via KAFKA-7785FailOnInvalidTimestamp Retrieves embedded metadata timestamps from Kafka messages.LogAndSkipOnInvalidTimestamp Retrieves embedded metadata timestamps from Kafka messages.MockProcessorContext MockProcessorContextis a mock ofProcessorContextfor users to test theirProcessor,Transformer, andValueTransformerimplementations.MockProcessorContext.CapturedForward MockProcessorContext.CapturedPunctuator MockProcessorContext.CapturedPunctuatorholds captured punctuators, along with their scheduling information.TaskId The task ID representation composed as topic group ID plus the assigned partition ID.TaskMetadata Represents the state of a single task running within aKafkaStreamsapplication.ThreadMetadata Represents the state of a single thread running within aKafkaStreamsapplication.To This class is used to provide the optional parameters when sending output records to downstream processor usingProcessorContext.forward(Object, Object, To).UsePartitionTimeOnInvalidTimestamp Retrieves embedded metadata timestamps from Kafka messages.UsePreviousTimeOnInvalidTimestamp Deprecated. since 2.5.WallclockTimestampExtractor Retrieves current wall clock timestamps asSystem.currentTimeMillis().
- 
Enum Summary Enum Description PunctuationType Controls what notion of time is used for punctuation scheduled viaProcessorContext.schedule(Duration, PunctuationType, Punctuator)schedule}: STREAM_TIME - uses "stream time", which is advanced by the processing of messages in accordance with the timestamp as extracted by theTimestampExtractorin use.