Interface | Description |
---|---|
ChangelogReader |
Performs bulk read operations from a set of partitions.
|
GlobalStateManager | |
InternalProcessorContext |
For internal use so we can update the
RecordContext and current
ProcessorNode when we are forwarding items that have been evicted or flushed from
ThreadCache |
ProcessorNodePunctuator | |
RecordBatchingStateRestoreCallback | |
RecordCollector | |
RecordCollector.Supplier |
A supplier of a
RecordCollectorImpl instance. |
RestoringTasks | |
StreamTask.ProducerSupplier | |
StreamThread.StateListener |
Listen to state change events
|
Task | |
ThreadStateTransitionValidator |
Basic interface for keeping track of the state of a thread.
|
TimestampSupplier |
Class | Description |
---|---|
AbstractProcessorContext | |
AbstractTask | |
CompositeRestoreListener | |
DefaultKafkaClientSupplier | |
DefaultStreamPartitioner<K,V> | |
ForwardingDisabledProcessorContext |
ProcessorContext implementation that will throw on any forward call. |
GlobalProcessorContextImpl | |
GlobalStateManagerImpl |
This class is responsible for the initialization, restoration, closing, flushing etc
of Global State Stores.
|
GlobalStateUpdateTask |
Updates the state for all Global State Stores.
|
GlobalStreamThread |
This is the thread responsible for keeping all Global State Stores updated.
|
InternalTopicConfig |
InternalTopicConfig captures the properties required for configuring
the internal topics we create for change-logs and repartitioning etc.
|
InternalTopicManager | |
InternalTopologyBuilder | |
InternalTopologyBuilder.AbstractNode | |
InternalTopologyBuilder.GlobalStore | |
InternalTopologyBuilder.Processor | |
InternalTopologyBuilder.Sink | |
InternalTopologyBuilder.Source | |
InternalTopologyBuilder.StateStoreFactory | |
InternalTopologyBuilder.SubscriptionUpdates |
Used to capture subscribed topic via Patterns discovered during the
partition assignment process.
|
InternalTopologyBuilder.Subtopology | |
InternalTopologyBuilder.TopicsInfo | |
InternalTopologyBuilder.TopologyDescription | |
PartitionGroup |
A PartitionGroup is composed from a set of partitions.
|
PartitionGroup.RecordInfo | |
ProcessorContextImpl | |
ProcessorNode<K,V> | |
ProcessorRecordContext | |
ProcessorStateManager | |
ProcessorTopology | |
PunctuationQueue | |
PunctuationSchedule | |
QuickUnion<T> | |
RecordCollectorImpl | |
RecordQueue |
RecordQueue is a FIFO queue of
StampedRecord (ConsumerRecord + timestamp). |
RepartitionTopicConfig |
RepartitionTopicConfig captures the properties required for configuring
the repartition topics.
|
SinkNode<K,V> | |
SourceNode<K,V> | |
Stamped<V> | |
StampedRecord | |
StandbyTask |
A StandbyTask
|
StateDirectory |
Manages the directories where the state of Tasks owned by a
StreamThread are
stored. |
StateRestoreCallbackAdapter | |
StateRestorer | |
StaticTopicNameExtractor<K,V> |
Static topic name extractor
|
StoreChangelogReader | |
StreamsMetadataState |
Provides access to the
StreamsMetadata in a KafkaStreams application. |
StreamsPartitionAssignor | |
StreamTask |
A StreamTask is associated with a
PartitionGroup , and is assigned to a StreamThread for processing. |
StreamTask.TaskMetrics | |
StreamThread | |
TaskManager | |
ToInternal | |
UnwindowedChangelogTopicConfig |
UnwindowedChangelogTopicConfig captures the properties required for configuring
the un-windowed store changelog topics.
|
WindowedChangelogTopicConfig |
WindowedChangelogTopicConfig captures the properties required for configuring
the windowed store changelog topics.
|
Enum | Description |
---|---|
GlobalStreamThread.State |
The states that the global stream thread can be in
|
StreamsPartitionAssignor.Error | |
StreamThread.State |
Stream thread states are the possible states that a stream thread can be in.
|