Abstract class for fetching data from multiple partitions from the same broker.
This class saves broker's metadata to a file
Broker states are the possible state that a kafka broker can be in.
The ClientIdConfigHandler will process clientId config changes in ZK.
Helper class that records per-client metrics.
Configuration settings for quota management
The ConfigHandler is used to process config change notifications received by the DynamicConfigManager
A delayed fetch operation that can be created by the replica manager and watched in the fetch operation purgatory
An operation whose processing needs to be delayed for at most the given delayMs.
Keys used for delayed operation metrics recording
A helper purgatory class for bookkeeping delayed operations with a timeout, and expiring timed out operations.
A delayed produce operation that can be created by the replica manager and watched in the produce operation purgatory
This class initiates and carries out config changes for all entities defined in ConfigType.
The fetch metadata maintained by the delayed fetch operation
Logic to handle the various Kafka requests
This class registers the broker in zookeeper to allow other brokers and consumers to detect failures.
A thread that answers kafka requests.
Represents the lifecycle of a single Kafka broker.
This trait defines a leader elector If the existing leader is dead, this class will handle automatic re-election and if it succeeds, it invokes the leader state change callback
This class saves out a map of topic/partition=>offsets to a file
case class to keep partition offset and its state(active , inactive)
The produce metadata maintained by the delayed produce operation
The TopicConfigHandler will process topic config changes in ZK.
This class handles zookeeper based leader election based on an ephemeral path.
Represents all the entities that can be configured via ZK