kafka

controller

package controller

Visibility
  1. Public
  2. All

Type Members

  1. class ControlledShutdownLeaderSelector extends PartitionLeaderSelector with Logging

    Picks one of the alive replicas (other than the current leader) in ISR as new leader, fails if there are no other replicas in ISR.

  2. class ControllerBrokerRequestBatch extends Logging

  3. case class ControllerBrokerStateInfo(channel: BlockingChannel, broker: Broker, messageQueue: BlockingQueue[(RequestOrResponse, (RequestOrResponse) ⇒ Unit)], requestSendThread: RequestSendThread) extends Product with Serializable

  4. class ControllerChannelManager extends Logging

  5. class ControllerContext extends AnyRef

  6. class ControllerEpochListener extends IZkDataListener with Logging

  7. class KafkaController extends Logging with KafkaMetricsGroup with KafkaControllerMBean

  8. trait KafkaControllerMBean extends AnyRef

  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

    This API selects a new leader for the input partition - 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

    Picks the preferred replica as the new leader if - 1.

  19. class ReassignedPartitionLeaderSelector extends PartitionLeaderSelector with Logging

    Picks one of the alive in-sync reassigned replicas as the new leader.

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

  21. class ReassignedPartitionsIsrChangeListener extends IZkDataListener with Logging

  22. sealed trait ReplicaState extends AnyRef

  23. class ReplicaStateMachine extends Logging

    This class represents the state machine for replicas.

  24. class RequestSendThread extends ShutdownableThread

Value Members

  1. object ControllerStats extends KafkaMetricsGroup

  2. object KafkaController extends Logging

  3. object NewPartition extends PartitionState with Product with Serializable

  4. object NewReplica extends ReplicaState with Product with Serializable

  5. object NonExistentPartition extends PartitionState with Product with Serializable

  6. object NonExistentReplica extends ReplicaState with Product with Serializable

  7. object OfflinePartition extends PartitionState with Product with Serializable

  8. object OfflineReplica extends ReplicaState with Product with Serializable

  9. object OnlinePartition extends PartitionState with Product with Serializable

  10. object OnlineReplica extends ReplicaState with Product with Serializable

Ungrouped