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. class ControllerBrokerStateInfo(channel: BlockingChannel, broker: Broker, messageQueue: BlockingQueue[(RequestOrResponse, (RequestOrResponse) ⇒ Unit)], requestSendThread: RequestSendThread) extends Product

  5. class ControllerChannelManager extends Logging

  6. class ControllerContext extends AnyRef

  7. class ControllerEpochListener extends IZkDataListener with Logging

  8. class KafkaController extends Logging with KafkaMetricsGroup with KafkaControllerMBean

  9. trait KafkaControllerMBean extends AnyRef

  10. class LeaderIsrAndControllerEpoch(leaderAndIsr: LeaderAndIsr, controllerEpoch: Int) extends Product

  11. class NoOpLeaderSelector extends PartitionLeaderSelector with Logging

    Essentially does nothing.

  12. class OfflinePartitionLeaderSelector extends PartitionLeaderSelector with Logging

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

  13. class PartitionAndReplica(topic: String, partition: Int, replica: Int) extends Product

  14. trait PartitionLeaderSelector extends AnyRef

  15. trait PartitionState extends AnyRef

    attributes: sealed
  16. class PartitionStateMachine extends Logging

    This class represents the state machine for partitions.

  17. class PartitionsReassignedListener extends IZkDataListener with Logging

    Starts the partition reassignment process unless - 1.

  18. class PreferredReplicaElectionListener extends IZkDataListener with Logging

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

  19. 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

  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. class ReassignedPartitionsContext(newReplicas: Seq[Int] = scala.collection.Seq.empty[Nothing], isrChangeListener: ReassignedPartitionsIsrChangeListener = null) extends Product

  22. class ReassignedPartitionsIsrChangeListener extends IZkDataListener with Logging

  23. trait ReplicaState extends AnyRef

    attributes: sealed
  24. class ReplicaStateMachine extends Logging

    This class represents the state machine for replicas.

  25. class RequestSendThread extends ShutdownableThread

  26. class StopReplicaRequestInfo(replica: PartitionAndReplica, deletePartition: Boolean, callback: (RequestOrResponse) ⇒ Unit = null) extends Product

  27. class TopicDeletionManager extends Logging

    This manages the state machine for topic deletion.

Value Members

  1. object Callbacks extends AnyRef

  2. object ControllerStats extends KafkaMetricsGroup

  3. object KafkaController extends Logging

  4. object NewPartition extends PartitionState with Product

  5. object NewReplica extends ReplicaState with Product

  6. object NonExistentPartition extends PartitionState with Product

  7. object NonExistentReplica extends ReplicaState with Product

  8. object OfflinePartition extends PartitionState with Product

  9. object OfflineReplica extends ReplicaState with Product

  10. object OnlinePartition extends PartitionState with Product

  11. object OnlineReplica extends ReplicaState with Product

  12. object ReplicaDeletionIneligible extends ReplicaState with Product

  13. object ReplicaDeletionStarted extends ReplicaState with Product

  14. object ReplicaDeletionSuccessful extends ReplicaState with Product