kafka

common

package common

Visibility
  1. Public
  2. All

Type Members

  1. class AdminCommandFailedException extends RuntimeException

  2. class BrokerNotAvailableException extends RuntimeException

  3. class ClientIdAndBroker(clientId: String, brokerInfo: String) extends Product

    Convenience case class since (clientId, brokerInfo) pairs are used to create SyncProducer Request Stats and SimpleConsumer Request and Response Stats.

  4. class ClientIdAndTopic(clientId: String, topic: String) extends Product

    Convenience case class since (clientId, topic) pairs are used in the creation of many Stats objects.

  5. trait Config extends Logging

  6. class ConsumerRebalanceFailedException extends RuntimeException

    Thrown when a request is made for broker but no brokers with that topic exist.

  7. class ControllerMovedException extends RuntimeException

  8. class FailedToSendMessageException extends RuntimeException

    Indicates a producer pool initialization problem

  9. class InvalidConfigException extends RuntimeException

    Indicates that the given config parameter has invalid value

  10. class InvalidMessageSizeException extends RuntimeException

    Indicates the client has requested a range no longer available on the server

  11. class InvalidOffsetException extends RuntimeException

  12. class InvalidTopicException extends RuntimeException

  13. class KafkaException extends RuntimeException

    Generic Kafka exception

  14. class KafkaStorageException extends RuntimeException

    Kafka exception caused by real IOs.

  15. class LeaderElectionNotNeededException extends RuntimeException

    This exception is thrown when new leader election is not necessary.

  16. class LeaderNotAvailableException extends RuntimeException

    Thrown when a request is made for partition, but no leader exists for that partition

  17. class LogCleaningAbortedException extends RuntimeException

    Thrown when a log cleaning task is requested to be aborted.

  18. class MessageSizeTooLargeException extends RuntimeException

  19. class NoBrokersForPartitionException extends RuntimeException

    Thrown when a request is made for broker but no brokers with that topic exist.

  20. class NoEpochForPartitionException extends RuntimeException

    Thrown when a get epoch request is made for partition, but no epoch exists for that partition

  21. class NoReplicaOnlineException extends RuntimeException

    This exception is thrown by the leader elector in the controller when leader election fails for a partition since all the replicas for a partition are offline

  22. class NotAssignedReplicaException extends RuntimeException

  23. class NotLeaderForPartitionException extends RuntimeException

    Thrown when a request is made for partition on a broker that is NOT a leader for that partition

  24. class OffsetMetadataAndError(offset: Long, metadata: String = OffsetMetadataAndError.NoMetadata, error: Short = ErrorMapping.NoError) extends Product

    Convenience case class since (topic, partition) pairs are ubiquitous.

  25. class OffsetMetadataTooLargeException extends RuntimeException

    Indicates the client has specified offset metadata that exceeds the configured maximum size in bytes

  26. class OffsetOutOfRangeException extends RuntimeException

    Indicates the client has requested a range no longer available on the server

  27. class QueueFullException extends RuntimeException

  28. class ReplicaNotAvailableException extends RuntimeException

    Thrown when a request is made for partition, but no leader exists for that partition

  29. class RequestTimedOutException extends RuntimeException

    Thrown when a produce request times out - i.

  30. class StateChangeFailedException extends RuntimeException

  31. class ThreadShutdownException extends RuntimeException

    An exception that indicates a thread is being shut down normally.

  32. class TopicAndPartition(topic: String, partition: Int) extends Product

    Convenience case class since (topic, partition) pairs are ubiquitous.

  33. class TopicExistsException extends RuntimeException

  34. class UnavailableProducerException extends RuntimeException

    Indicates a producer pool initialization problem

  35. class UnknownCodecException extends RuntimeException

    Indicates the client has requested a range no longer available on the server

  36. class UnknownException extends RuntimeException

    If we don't know what else it is, call it this

  37. class UnknownMagicByteException extends RuntimeException

    Indicates the client has requested a range no longer available on the server

  38. class UnknownTopicOrPartitionException extends RuntimeException

    Indicates an unknown topic or a partition id not between 0 and numPartitions-1

Value Members

  1. object ErrorMapping extends AnyRef

    A bi-directional mapping between error codes and exceptions x

  2. object OffsetMetadataAndError extends AnyRef

  3. object Topic extends AnyRef