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

  5. class ControllerChannelManager extends Logging

  6. class ControllerContext extends AnyRef

  7. class KafkaController extends Logging with KafkaMetricsGroup

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

  9. class NoOpLeaderSelector extends PartitionLeaderSelector with Logging

    Essentially does nothing.

  10. class OfflinePartitionLeaderSelector extends PartitionLeaderSelector with Logging

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

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

  12. trait PartitionLeaderSelector extends AnyRef

  13. sealed trait PartitionState extends AnyRef

  14. class PartitionStateMachine extends Logging

    This class represents the state machine for partitions.

  15. class PartitionsReassignedListener extends IZkDataListener with Logging

    Starts the partition reassignment process unless - 1.

  16. class PreferredReplicaElectionListener extends IZkDataListener with Logging

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

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

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

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

  20. class ReassignedPartitionsIsrChangeListener extends IZkDataListener with Logging

  21. sealed trait ReplicaState extends AnyRef

  22. class ReplicaStateMachine extends Logging

    This class represents the state machine for replicas.

  23. class RequestSendThread extends ShutdownableThread

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

  25. class TopicDeletionManager extends Logging

    This manages the state machine for topic deletion.

Value Members

  1. object Callbacks

  2. object ControllerStats extends KafkaMetricsGroup

  3. object KafkaController extends Logging

  4. object NewPartition extends PartitionState with Product with Serializable

  5. object NewReplica extends ReplicaState with Product with Serializable

  6. object NonExistentPartition extends PartitionState with Product with Serializable

  7. object NonExistentReplica extends ReplicaState with Product with Serializable

  8. object OfflinePartition extends PartitionState with Product with Serializable

  9. object OfflineReplica extends ReplicaState with Product with Serializable

  10. object OnlinePartition extends PartitionState with Product with Serializable

  11. object OnlineReplica extends ReplicaState with Product with Serializable

  12. object ReplicaDeletionIneligible extends ReplicaState with Product with Serializable

  13. object ReplicaDeletionStarted extends ReplicaState with Product with Serializable

  14. object ReplicaDeletionSuccessful extends ReplicaState with Product with Serializable

Ungrouped