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 BrokerAndFetcherId(broker: Broker, fetcherId: Int) extends Product with Serializable

  4. case class BrokerAndInitialOffset(broker: Broker, initOffset: Long) extends Product with Serializable

  5. case class BrokerState() extends Product with Serializable

  6. sealed trait BrokerStates extends AnyRef

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

  7. class BrokerTopicMetrics extends KafkaMetricsGroup

  8. case class ClientIdBrokerTopicPartition(clientId: String, brokerInfo: String, topic: String, partitionId: Int) extends Product with Serializable

  9. class DelayedFetch extends DelayedRequest

    A delayed fetch request, which is satisfied (or more accurately, unblocked) -- if: Case A: This broker is no longer the leader for some partitions it tries to fetch

  10. class DelayedProduce extends DelayedRequest with Logging

    A delayed produce request, which is satisfied (or more accurately, unblocked) -- if for every partition it produce to: Case A: This broker is not the leader: unblock - should return error.

  11. case class DelayedProduceResponseStatus(requiredOffset: Long, responseStatus: ProducerResponseStatus) extends Product with Serializable

  12. class DelayedRequest extends DelayedItem[Request]

    A request whose processing needs to be delayed for at most the given delayMs The associated keys are used for bookeeping, and represent the "trigger" that causes this request to check if it is satisfied, for example a key could be a (topic, partition) pair.

  13. trait DelayedRequestKey extends AnyRef

    Keys used for delayed request metrics recording

  14. case class FetchDataInfo(fetchOffset: LogOffsetMetadata, messageSet: MessageSet) extends Product with Serializable

  15. class FetchRequestPurgatory extends RequestPurgatory[DelayedFetch]

    The purgatory holding delayed fetch requests

  16. class FetcherLagMetrics extends KafkaMetricsGroup

  17. class FetcherLagStats extends AnyRef

  18. class FetcherStats extends KafkaMetricsGroup

  19. case class GroupTopicPartition(group: String, topicPartition: TopicAndPartition) extends Product with Serializable

  20. class KafkaApis extends Logging

    Logic to handle the various Kafka requests

  21. class KafkaConfig extends ZKConfig

    Configuration settings for the kafka server

  22. class KafkaHealthcheck extends Logging

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

  23. class KafkaRequestHandler extends Runnable with Logging

    A thread that answers kafka requests.

  24. class KafkaRequestHandlerPool extends Logging with KafkaMetricsGroup

  25. class KafkaServer extends Logging with KafkaMetricsGroup

    Represents the lifecycle of a single Kafka broker.

  26. class KafkaServerStartable extends Logging

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

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

  29. class OffsetCheckpoint extends Logging

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

  30. class OffsetManager extends Logging with KafkaMetricsGroup

  31. case class OffsetManagerConfig(maxMetadataSize: Int, loadBufferSize: Int, offsetsRetentionMs: Long, offsetsRetentionCheckIntervalMs: Long, offsetsTopicNumPartitions: Int, offsetsTopicSegmentBytes: Int, offsetsTopicReplicationFactor: Short, offsetsTopicCompressionCodec: CompressionCodec, offsetCommitTimeoutMs: Int, offsetCommitRequiredAcks: Short) extends Product with Serializable

    Configuration settings for in-built offset management

  32. case class PartitionDataAndOffset(data: FetchResponsePartitionData, offset: LogOffsetMetadata) extends Product with Serializable

  33. class ProducerRequestPurgatory extends RequestPurgatory[DelayedProduce]

    The purgatory holding delayed producer requests

  34. class ReplicaFetcherManager extends AbstractFetcherManager

  35. class ReplicaFetcherThread extends AbstractFetcherThread

  36. class ReplicaManager extends Logging with KafkaMetricsGroup

  37. abstract class RequestPurgatory[T <: DelayedRequest] extends Logging with KafkaMetricsGroup

    A helper class for dealing with asynchronous requests with a timeout.

  38. class TopicConfigManager extends Logging

    This class initiates and carries out topic config changes.

  39. case class TopicPartitionRequestKey(topic: String, partition: Int) extends DelayedRequestKey with Product with Serializable

  40. class ZookeeperLeaderElector extends LeaderElector with Logging

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

Value Members

  1. object BrokerShuttingDown extends BrokerStates with Product with Serializable

  2. object BrokerTopicStats extends Logging

  3. object DelayedRequestKey extends AnyRef

  4. object LogOffsetMetadata extends Serializable

  5. object NotRunning extends BrokerStates with Product with Serializable

  6. object OffsetManager extends AnyRef

  7. object OffsetManagerConfig extends Serializable

  8. object PendingControlledShutdown extends BrokerStates with Product with Serializable

  9. object RecoveringFromUncleanShutdown extends BrokerStates with Product with Serializable

  10. object ReplicaManager extends AnyRef

  11. object RunningAsBroker extends BrokerStates with Product with Serializable

  12. object RunningAsController extends BrokerStates with Product with Serializable

  13. object Starting extends BrokerStates with Product with Serializable