Class/Object

kafka.server

ReplicaManager

Related Docs: object ReplicaManager | package server

Permalink

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
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] = None)

    Permalink

Value Members

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

    Permalink
    Definition Classes
    AnyRef → Any
  2. final def ##(): Int

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

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

    Permalink

    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

  5. final def asInstanceOf[T0]: T0

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

    Permalink
  7. def checkpointHighWatermarks(): Unit

    Permalink
  8. def clone(): AnyRef

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

    Permalink
  10. var controllerEpoch: Int

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

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

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

    Permalink
    Definition Classes
    Logging
  14. val delayedFetchPurgatory: DelayedOperationPurgatory[DelayedFetch]

    Permalink
  15. val delayedProducePurgatory: DelayedOperationPurgatory[DelayedProduce]

    Permalink
  16. final def eq(arg0: AnyRef): Boolean

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

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

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

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

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

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

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

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

    Permalink

    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

  25. def finalize(): Unit

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

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

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

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

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

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

    Permalink
  32. def hashCode(): Int

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

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

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

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

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

    Permalink
    Definition Classes
    Any
  38. val isShuttingDown: AtomicBoolean

    Permalink
  39. val isrExpandRate: Meter

    Permalink
  40. val isrShrinkRate: Meter

    Permalink
  41. val leaderCount: Gauge[Int]

    Permalink
  42. var logIdent: String

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  43. val logManager: LogManager

    Permalink
  44. lazy val logger: Logger

    Permalink
    Definition Classes
    Logging
  45. val loggerName: String

    Permalink
    Definition Classes
    Logging
  46. def maybePropagateIsrChanges(): Unit

    Permalink

    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.

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

    Permalink
  48. final def ne(arg0: AnyRef): Boolean

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

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

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

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

    Permalink
    Definition Classes
    KafkaMetricsGroup
  53. final def notify(): Unit

    Permalink
    Definition Classes
    AnyRef
  54. final def notifyAll(): Unit

    Permalink
    Definition Classes
    AnyRef
  55. val partitionCount: Gauge[Int]

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

    Permalink

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

  57. def recordIsrChange(topicAndPartition: TopicAndPartition): Unit

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

    Permalink
    Definition Classes
    KafkaMetricsGroup
  59. val replicaFetcherManager: ReplicaFetcherManager

    Permalink
  60. def shutdown(checkpointHW: Boolean = true): Unit

    Permalink
  61. def startHighWaterMarksCheckPointThread(): Unit

    Permalink
  62. def startup(): Unit

    Permalink
  63. val stateChangeLogger: StateChangeLogger

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

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

    Permalink
  66. def swallow(action: ⇒ Unit): Unit

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

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

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

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

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

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

    Permalink
    Definition Classes
    AnyRef
  73. def toString(): String

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

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

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

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

    Permalink

    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)

  78. def tryCompleteDelayedProduce(key: DelayedOperationKey): Unit

    Permalink

    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)

  79. def underReplicatedPartitionCount(): Int

    Permalink
  80. val underReplicatedPartitions: Gauge[Int]

    Permalink
  81. final def wait(): Unit

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

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

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

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

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

    Permalink
    Definition Classes
    Logging
  87. val zkUtils: ZkUtils

    Permalink

Inherited from KafkaMetricsGroup

Inherited from Logging

Inherited from AnyRef

Inherited from Any

Ungrouped