kafka

server

package server

Visibility
  1. Public
  2. All

Type Members

  1. abstract class AbstractFetcherManager extends Logging with KafkaMetricsGroup

  2. abstract class AbstractFetcherThread extends ShutdownableThread

    Abstract class for fetching data from multiple partitions from the same broker.

  3. case class BecomeLeaderOrFollowerResult(responseMap: Map[(String, Int), Short], errorCode: Short) extends Product with Serializable

  4. case class BrokerAndFetcherId(broker: BrokerEndPoint, fetcherId: Int) extends Product with Serializable

  5. case class BrokerAndInitialOffset(broker: BrokerEndPoint, initOffset: Long) extends Product with Serializable

  6. case class BrokerMetadata(brokerId: Int) extends Product with Serializable

  7. class BrokerMetadataCheckpoint extends Logging

    This class saves broker's metadata to a file

  8. case class BrokerState() extends Product with Serializable

  9. sealed trait BrokerStates extends AnyRef

    Broker states are the possible state that a kafka broker can be in.

  10. class BrokerTopicMetrics extends KafkaMetricsGroup

  11. class ClientIdConfigHandler extends ConfigHandler

    The ClientIdConfigHandler will process clientId config changes in ZK.

  12. case class ClientIdTopicPartition(clientId: String, topic: String, partitionId: Int) extends Product with Serializable

  13. class ClientQuotaManager extends Logging

    Helper class that records per-client metrics.

  14. case class ClientQuotaManagerConfig(quotaBytesPerSecondDefault: Long = ..., numQuotaSamples: Int = ..., quotaWindowSizeSeconds: Int = ...) extends Product with Serializable

    Configuration settings for quota management

  15. trait ConfigHandler extends AnyRef

    The ConfigHandler is used to process config change notifications received by the DynamicConfigManager

  16. class DelayedFetch extends DelayedOperation

    A delayed fetch operation that can be created by the replica manager and watched in the fetch operation purgatory

  17. abstract class DelayedOperation extends TimerTask with Logging

    An operation whose processing needs to be delayed for at most the given delayMs.

  18. trait DelayedOperationKey extends AnyRef

    Keys used for delayed operation metrics recording

  19. class DelayedOperationPurgatory[T <: DelayedOperation] extends Logging with KafkaMetricsGroup

    A helper purgatory class for bookkeeping delayed operations with a timeout, and expiring timed out operations.

  20. class DelayedProduce extends DelayedOperation

    A delayed produce operation that can be created by the replica manager and watched in the produce operation purgatory

  21. class DynamicConfigManager extends Logging

    This class initiates and carries out config changes for all entities defined in ConfigType.

  22. case class FetchDataInfo(fetchOffsetMetadata: LogOffsetMetadata, messageSet: MessageSet) extends Product with Serializable

  23. case class FetchMetadata(fetchMinBytes: Int, fetchOnlyLeader: Boolean, fetchOnlyCommitted: Boolean, isFromFollower: Boolean, fetchPartitionStatus: Map[TopicAndPartition, FetchPartitionStatus]) extends Product with Serializable

    The fetch metadata maintained by the delayed fetch operation

  24. case class FetchPartitionStatus(startOffsetMetadata: LogOffsetMetadata, fetchInfo: PartitionFetchInfo) extends Product with Serializable

  25. class FetcherLagMetrics extends KafkaMetricsGroup

  26. class FetcherLagStats extends AnyRef

  27. class FetcherStats extends KafkaMetricsGroup

  28. case class GroupKey(groupId: String) extends DelayedOperationKey with Product with Serializable

  29. class KafkaApis extends Logging

    Logic to handle the various Kafka requests

  30. case class KafkaConfig(props: Map[_, _]) extends AbstractConfig with Product with Serializable

  31. class KafkaHealthcheck extends Logging

    This class registers the broker in zookeeper to allow other brokers and consumers to detect failures.

  32. class KafkaRequestHandler extends Runnable with Logging

    A thread that answers kafka requests.

  33. class KafkaRequestHandlerPool extends Logging with KafkaMetricsGroup

  34. class KafkaServer extends Logging with KafkaMetricsGroup

    Represents the lifecycle of a single Kafka broker.

  35. class KafkaServerStartable extends Logging

  36. trait LeaderElector extends Logging

    This trait defines a leader elector If the existing leader is dead, this class will handle automatic re-election and if it succeeds, it invokes the leader state change callback

  37. case class LogAppendResult(info: LogAppendInfo, error: Option[Throwable] = scala.None) extends Product with Serializable

  38. case class LogOffsetMetadata(messageOffset: Long, segmentBaseOffset: Long = ..., relativePositionInSegment: Int = ...) extends Product with Serializable

  39. case class LogReadResult(info: FetchDataInfo, hw: Long, readSize: Int, isReadFromLogEnd: Boolean, error: Option[Throwable] = scala.None) extends Product with Serializable

  40. case class MemberKey(groupId: String, consumerId: String) extends DelayedOperationKey with Product with Serializable

  41. class OffsetCheckpoint extends Logging

    This class saves out a map of topic/partition=>offsets to a file

  42. case class PartitionFetchState(offset: Long, delay: DelayedItem) extends Product with Serializable

    case class to keep partition offset and its state(active , inactive)

  43. case class ProduceMetadata(produceRequiredAcks: Short, produceStatus: Map[TopicAndPartition, ProducePartitionStatus]) extends Product with Serializable

    The produce metadata maintained by the delayed produce operation

  44. case class ProducePartitionStatus(requiredOffset: Long, responseStatus: ProducerResponseStatus) extends Product with Serializable

  45. class ReplicaFetcherManager extends AbstractFetcherManager

  46. class ReplicaFetcherThread extends AbstractFetcherThread

  47. class ReplicaManager extends Logging with KafkaMetricsGroup

  48. class TopicConfigHandler extends ConfigHandler

    The TopicConfigHandler will process topic config changes in ZK.

  49. case class TopicPartitionOperationKey(topic: String, partition: Int) extends DelayedOperationKey with Product with Serializable

  50. class ZookeeperLeaderElector extends LeaderElector with Logging

    This class handles zookeeper based leader election based on an ephemeral path.

Value Members

  1. object AbstractFetcherThread

  2. object BrokerShuttingDown extends BrokerStates with Product with Serializable

  3. object BrokerTopicStats extends Logging

  4. object ClientConfigOverride

  5. object ClientQuotaManagerConfig extends Serializable

  6. object ConfigType

    Represents all the entities that can be configured via ZK

  7. object Defaults

  8. object DelayedFetchMetrics extends KafkaMetricsGroup

  9. object DelayedOperationKey

  10. object DelayedProduceMetrics extends KafkaMetricsGroup

  11. object KafkaConfig extends Serializable

  12. object KafkaServer

  13. object KafkaServerStartable

  14. object LogOffsetMetadata extends Serializable

  15. object LogReadResult extends Serializable

  16. object NotRunning extends BrokerStates with Product with Serializable

  17. object PendingControlledShutdown extends BrokerStates with Product with Serializable

  18. object RecoveringFromUncleanShutdown extends BrokerStates with Product with Serializable

  19. object ReplicaFetcherThread

  20. object ReplicaManager

  21. object RunningAsBroker extends BrokerStates with Product with Serializable

  22. object RunningAsController extends BrokerStates with Product with Serializable

  23. object Starting extends BrokerStates with Product with Serializable

Ungrouped