kafka.server

ReplicaManager

class ReplicaManager extends Logging with KafkaMetricsGroup

Linear Supertypes
Ordering
  1. Alphabetic
  2. By inheritance
Inherited
  1. ReplicaManager
  2. KafkaMetricsGroup
  3. Logging
  4. AnyRef
  5. Any
  1. Hide All
  2. Show all
Learn more about member selection
Visibility
  1. Public
  2. All

Instance Constructors

  1. new ReplicaManager(config: KafkaConfig, metrics: Metrics, time: Time, jTime: Time, zkUtils: ZkUtils, scheduler: Scheduler, logManager: LogManager, isShuttingDown: AtomicBoolean, threadNamePrefix: Option[String] = scala.None)

Value Members

  1. final def !=(arg0: AnyRef): Boolean

    Definition Classes
    AnyRef
  2. final def !=(arg0: Any): Boolean

    Definition Classes
    Any
  3. final def ##(): Int

    Definition Classes
    AnyRef → Any
  4. final def ==(arg0: AnyRef): Boolean

    Definition Classes
    AnyRef
  5. final def ==(arg0: Any): Boolean

    Definition Classes
    Any
  6. def appendMessages(timeout: Long, requiredAcks: Short, internalTopicsAllowed: Boolean, messagesPerPartition: Map[TopicAndPartition, MessageSet], responseCallback: (Map[TopicAndPartition, ProducerResponseStatus]) ⇒ Unit): Unit

    Append messages to leader replicas of the partition, and wait for them to be replicated to other replicas; the callback function will be triggered either when timeout or the required acks are satisfied

  7. final def asInstanceOf[T0]: T0

    Definition Classes
    Any
  8. def becomeLeaderOrFollower(leaderAndISRRequest: LeaderAndIsrRequest, metadataCache: MetadataCache, onLeadershipChange: (Iterable[Partition], Iterable[Partition]) ⇒ Unit): BecomeLeaderOrFollowerResult

  9. def checkpointHighWatermarks(): Unit

  10. def clone(): AnyRef

    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  11. val config: KafkaConfig

  12. var controllerEpoch: Int

  13. def debug(msg: ⇒ String, e: ⇒ Throwable): Unit

    Definition Classes
    Logging
  14. def debug(e: ⇒ Throwable): Any

    Definition Classes
    Logging
  15. def debug(msg: ⇒ String): Unit

    Definition Classes
    Logging
  16. val delayedFetchPurgatory: DelayedOperationPurgatory[DelayedFetch]

  17. val delayedProducePurgatory: DelayedOperationPurgatory[DelayedProduce]

  18. final def eq(arg0: AnyRef): Boolean

    Definition Classes
    AnyRef
  19. def equals(arg0: Any): Boolean

    Definition Classes
    AnyRef → Any
  20. def error(msg: ⇒ String, e: ⇒ Throwable): Unit

    Definition Classes
    Logging
  21. def error(e: ⇒ Throwable): Any

    Definition Classes
    Logging
  22. def error(msg: ⇒ String): Unit

    Definition Classes
    Logging
  23. def fatal(msg: ⇒ String, e: ⇒ Throwable): Unit

    Definition Classes
    Logging
  24. def fatal(e: ⇒ Throwable): Any

    Definition Classes
    Logging
  25. def fatal(msg: ⇒ String): Unit

    Definition Classes
    Logging
  26. def fetchMessages(timeout: Long, replicaId: Int, fetchMinBytes: Int, fetchInfo: Map[TopicAndPartition, PartitionFetchInfo], responseCallback: (Map[TopicAndPartition, FetchResponsePartitionData]) ⇒ Unit): Unit

    Fetch messages from the leader replica, and wait until enough data can be fetched and return; the callback function will be triggered either when timeout or required fetch info is satisfied

  27. def finalize(): Unit

    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( classOf[java.lang.Throwable] )
  28. final def getClass(): Class[_]

    Definition Classes
    AnyRef → Any
  29. def getLeaderReplicaIfLocal(topic: String, partitionId: Int): Replica

  30. def getOrCreatePartition(topic: String, partitionId: Int): Partition

  31. def getPartition(topic: String, partitionId: Int): Option[Partition]

  32. def getReplica(topic: String, partitionId: Int, replicaId: Int = config.brokerId): Option[Replica]

  33. def getReplicaOrException(topic: String, partition: Int): Replica

  34. def hashCode(): Int

    Definition Classes
    AnyRef → Any
  35. val highWatermarkCheckpoints: Map[String, OffsetCheckpoint]

  36. def info(msg: ⇒ String, e: ⇒ Throwable): Unit

    Definition Classes
    Logging
  37. def info(e: ⇒ Throwable): Any

    Definition Classes
    Logging
  38. def info(msg: ⇒ String): Unit

    Definition Classes
    Logging
  39. final def isInstanceOf[T0]: Boolean

    Definition Classes
    Any
  40. val isShuttingDown: AtomicBoolean

  41. val isrExpandRate: Meter

  42. val isrShrinkRate: Meter

  43. val leaderCount: Gauge[Int]

  44. var logIdent: String

    Attributes
    protected
    Definition Classes
    Logging
  45. val logManager: LogManager

  46. lazy val logger: Logger

    Definition Classes
    Logging
  47. val loggerName: String

    Definition Classes
    Logging
  48. def maybePropagateIsrChanges(): Unit

    This function periodically runs to see if ISR needs to be propagated.

    This function periodically runs to see if ISR needs to be propagated. It propagates ISR when: 1. There is ISR change not propagated yet. 2. There is no ISR Change in the last five seconds, or it has been more than 60 seconds since the last ISR propagation. This allows an occasional ISR change to be propagated within a few seconds, and avoids overwhelming controller and other brokers when large amount of ISR change occurs.

  49. def maybeUpdateMetadataCache(updateMetadataRequest: UpdateMetadataRequest, metadataCache: MetadataCache): Unit

  50. final def ne(arg0: AnyRef): Boolean

    Definition Classes
    AnyRef
  51. def newGauge[T](name: String, metric: Gauge[T], tags: Map[String, String] = Map.empty): Gauge[T]

    Definition Classes
    KafkaMetricsGroup
  52. def newHistogram(name: String, biased: Boolean = true, tags: Map[String, String] = Map.empty): Histogram

    Definition Classes
    KafkaMetricsGroup
  53. def newMeter(name: String, eventType: String, timeUnit: TimeUnit, tags: Map[String, String] = Map.empty): Meter

    Definition Classes
    KafkaMetricsGroup
  54. def newTimer(name: String, durationUnit: TimeUnit, rateUnit: TimeUnit, tags: Map[String, String] = Map.empty): Timer

    Definition Classes
    KafkaMetricsGroup
  55. final def notify(): Unit

    Definition Classes
    AnyRef
  56. final def notifyAll(): Unit

    Definition Classes
    AnyRef
  57. val partitionCount: Gauge[Int]

  58. def readFromLocalLog(fetchOnlyFromLeader: Boolean, readOnlyCommitted: Boolean, readPartitionInfo: Map[TopicAndPartition, PartitionFetchInfo]): Map[TopicAndPartition, LogReadResult]

    Read from a single topic/partition at the given offset upto maxSize bytes

  59. def recordIsrChange(topicAndPartition: TopicAndPartition): Unit

  60. def removeMetric(name: String, tags: Map[String, String] = Map.empty): Unit

    Definition Classes
    KafkaMetricsGroup
  61. val replicaFetcherManager: ReplicaFetcherManager

  62. def shutdown(checkpointHW: Boolean = true): Unit

  63. def startHighWaterMarksCheckPointThread(): Unit

  64. def startup(): Unit

  65. val stateChangeLogger: StateChangeLogger

  66. def stopReplica(topic: String, partitionId: Int, deletePartition: Boolean): Short

  67. def stopReplicas(stopReplicaRequest: StopReplicaRequest): (Map[TopicAndPartition, Short], Short)

  68. def swallow(action: ⇒ Unit): Unit

    Definition Classes
    Logging
  69. def swallowDebug(action: ⇒ Unit): Unit

    Definition Classes
    Logging
  70. def swallowError(action: ⇒ Unit): Unit

    Definition Classes
    Logging
  71. def swallowInfo(action: ⇒ Unit): Unit

    Definition Classes
    Logging
  72. def swallowTrace(action: ⇒ Unit): Unit

    Definition Classes
    Logging
  73. def swallowWarn(action: ⇒ Unit): Unit

    Definition Classes
    Logging
  74. final def synchronized[T0](arg0: ⇒ T0): T0

    Definition Classes
    AnyRef
  75. def toString(): String

    Definition Classes
    AnyRef → Any
  76. def trace(msg: ⇒ String, e: ⇒ Throwable): Unit

    Definition Classes
    Logging
  77. def trace(e: ⇒ Throwable): Any

    Definition Classes
    Logging
  78. def trace(msg: ⇒ String): Unit

    Definition Classes
    Logging
  79. def tryCompleteDelayedFetch(key: DelayedOperationKey): Unit

    Try to complete some delayed fetch requests with the request key; this can be triggered when:

    Try to complete some delayed fetch requests with the request key; this can be triggered when:

    1. The partition HW has changed (for regular fetch) 2. A new message set is appended to the local log (for follower fetch)

  80. def tryCompleteDelayedProduce(key: DelayedOperationKey): Unit

    Try to complete some delayed produce requests with the request key; this can be triggered when:

    Try to complete some delayed produce requests with the request key; this can be triggered when:

    1. The partition HW has changed (for acks = -1) 2. A follower replica's fetch operation is received (for acks > 1)

  81. def underReplicatedPartitionCount(): Int

  82. val underReplicatedPartitions: Gauge[Int]

  83. final def wait(): Unit

    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  84. final def wait(arg0: Long, arg1: Int): Unit

    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  85. final def wait(arg0: Long): Unit

    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  86. def warn(msg: ⇒ String, e: ⇒ Throwable): Unit

    Definition Classes
    Logging
  87. def warn(e: ⇒ Throwable): Any

    Definition Classes
    Logging
  88. def warn(msg: ⇒ String): Unit

    Definition Classes
    Logging
  89. val zkUtils: ZkUtils

Inherited from KafkaMetricsGroup

Inherited from Logging

Inherited from AnyRef

Inherited from Any

Ungrouped