kafka

controller

package controller

Visibility
  1. Public
  2. All

Type Members

  1. class Callbacks extends AnyRef

  2. class ControlledShutdownLeaderSelector extends PartitionLeaderSelector with Logging

    New leader = replica in isr that's not being shutdown; New isr = current isr - shutdown replica; Replicas to receive LeaderAndIsr request = live assigned replicas

  3. class ControllerBrokerRequestBatch extends Logging

  4. case class ControllerBrokerStateInfo(networkClient: NetworkClient, brokerNode: Node, messageQueue: BlockingQueue[QueueItem], requestSendThread: RequestSendThread) extends Product with Serializable

  5. class ControllerChannelManager extends Logging

  6. class ControllerContext extends AnyRef

  7. class IsrChangeNotificationListener extends IZkChildListener with Logging

    Called when leader intimates of isr change

  8. class KafkaController extends Logging with KafkaMetricsGroup

  9. case class LeaderIsrAndControllerEpoch(leaderAndIsr: LeaderAndIsr, controllerEpoch: Int) extends Product with Serializable

  10. class NoOpLeaderSelector extends PartitionLeaderSelector with Logging

    Essentially does nothing.

  11. class OfflinePartitionLeaderSelector extends PartitionLeaderSelector with Logging

    Select the new leader, new isr and receiving replicas (for the LeaderAndIsrRequest): 1.

  12. case class PartitionAndReplica(topic: String, partition: Int, replica: Int) extends Product with Serializable

  13. trait PartitionLeaderSelector extends AnyRef

  14. sealed trait PartitionState extends AnyRef

  15. class PartitionStateMachine extends Logging

    This class represents the state machine for partitions.

  16. class PartitionsReassignedListener extends IZkDataListener with Logging

    Starts the partition reassignment process unless - 1.

  17. class PreferredReplicaElectionListener extends IZkDataListener with Logging

    Starts the preferred replica leader election for the list of partitions specified under /admin/preferred_replica_election -

  18. class PreferredReplicaPartitionLeaderSelector extends PartitionLeaderSelector with Logging

    New leader = preferred (first assigned) replica (if in isr and alive); New isr = current isr; Replicas to receive LeaderAndIsr request = assigned replicas

  19. case class QueueItem(apiKey: ApiKeys, apiVersion: Option[Short], request: AbstractRequest, callback: (AbstractRequestResponse) ⇒ Unit) extends Product with Serializable

  20. class ReassignedPartitionLeaderSelector extends PartitionLeaderSelector with Logging

    New leader = a live in-sync reassigned replica New isr = current isr Replicas to receive LeaderAndIsr request = reassigned replicas

  21. case class ReassignedPartitionsContext(newReplicas: Seq[Int] = scala.collection.Seq.empty[Nothing], isrChangeListener: ReassignedPartitionsIsrChangeListener = null) extends Product with Serializable

  22. class ReassignedPartitionsIsrChangeListener extends IZkDataListener with Logging

  23. sealed trait ReplicaState extends AnyRef

  24. class ReplicaStateMachine extends Logging

    This class represents the state machine for replicas.

  25. class RequestSendThread extends ShutdownableThread

  26. case class StopReplicaRequestInfo(replica: PartitionAndReplica, deletePartition: Boolean, callback: (AbstractRequestResponse) ⇒ Unit = null) extends Product with Serializable

  27. class TopicDeletionManager extends Logging

    This manages the state machine for topic deletion.

Value Members

  1. object Callbacks

  2. object ControllerStats extends KafkaMetricsGroup

  3. object IsrChangeNotificationListener

  4. object KafkaController extends Logging

  5. object NewPartition extends PartitionState with Product with Serializable

  6. object NewReplica extends ReplicaState with Product with Serializable

  7. object NonExistentPartition extends PartitionState with Product with Serializable

  8. object NonExistentReplica extends ReplicaState with Product with Serializable

  9. object OfflinePartition extends PartitionState with Product with Serializable

  10. object OfflineReplica extends ReplicaState with Product with Serializable

  11. object OnlinePartition extends PartitionState with Product with Serializable

  12. object OnlineReplica extends ReplicaState with Product with Serializable

  13. object ReplicaDeletionIneligible extends ReplicaState with Product with Serializable

  14. object ReplicaDeletionStarted extends ReplicaState with Product with Serializable

  15. object ReplicaDeletionSuccessful extends ReplicaState with Product with Serializable

Ungrouped