kafka

common

package common

Visibility
  1. Public
  2. All

Type Members

  1. class AdminCommandFailedException extends RuntimeException

  2. abstract class AuthorizationException extends RuntimeException

    Exception thrown when a principal is not authorized to perform an operation.

  3. trait BaseEnum extends Product with Serializable

  4. class BrokerEndPointNotAvailableException extends RuntimeException

  5. class BrokerNotAvailableException extends RuntimeException

  6. case class ClientIdAllBrokers(clientId: String) extends ClientIdBroker with Product with Serializable

  7. case class ClientIdAllTopics(clientId: String) extends ClientIdTopic with Product with Serializable

  8. case class ClientIdAndBroker(clientId: String, brokerHost: String, brokerPort: Int) extends ClientIdBroker with Product with Serializable

  9. case class ClientIdAndTopic(clientId: String, topic: String) extends ClientIdTopic with Product with Serializable

  10. trait ClientIdBroker extends AnyRef

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

  11. trait ClientIdTopic extends AnyRef

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

  12. class ClusterAuthorizationException extends AuthorizationException

  13. trait Config extends Logging

  14. class ConsumerCoordinatorNotAvailableException extends RuntimeException

  15. class ConsumerRebalanceFailedException extends RuntimeException

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

  16. class ControllerMovedException extends RuntimeException

  17. class FailedToSendMessageException extends RuntimeException

    Indicates a producer pool initialization problem

  18. class GenerateBrokerIdException extends RuntimeException

    Thrown when there is a failure to generate a zookeeper sequenceId to use as brokerId

  19. class GroupAuthorizationException extends AuthorizationException

  20. class InconsistentBrokerIdException extends RuntimeException

    Indicates the brokerId stored in logDirs is not consistent across logDirs.

  21. class InvalidConfigException extends RuntimeException

    Indicates that the given config parameter has invalid value

  22. class InvalidMessageSizeException extends RuntimeException

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

  23. class InvalidOffsetException extends RuntimeException

  24. class InvalidTopicException extends RuntimeException

  25. class KafkaException extends RuntimeException

    Generic Kafka exception

  26. class KafkaStorageException extends RuntimeException

    Kafka exception caused by real IOs.

  27. class LeaderElectionNotNeededException extends RuntimeException

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

  28. class LeaderNotAvailableException extends RuntimeException

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

  29. class LogCleaningAbortedException extends RuntimeException

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

  30. class MessageSetSizeTooLargeException extends RuntimeException

  31. class MessageSizeTooLargeException extends RuntimeException

  32. class MessageStreamsExistException extends RuntimeException

    Indicates a createMessageStreams can't be called more thane once

  33. class NoBrokersForPartitionException extends RuntimeException

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

  34. class NoEpochForPartitionException extends RuntimeException

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

  35. 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 leader candidate replicas for a partition are offline; the set of candidates may or may not be limited to just the in sync replicas depending upon whether unclean leader election is allowed to occur.

  36. class NotAssignedReplicaException extends RuntimeException

  37. class NotCoordinatorForConsumerException extends RuntimeException

  38. class NotEnoughReplicasAfterAppendException extends RuntimeException

    Number of insync replicas for the partition is lower than min.

  39. class NotEnoughReplicasException extends RuntimeException

    Message was rejected because number of insync replicas for the partition is lower than min.

  40. class NotLeaderForPartitionException extends RuntimeException

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

  41. trait NotificationHandler extends AnyRef

    Handle the notificationMessage.

  42. case class OffsetAndMetadata(offsetMetadata: OffsetMetadata, commitTimestamp: Long = ..., expireTimestamp: Long = ...) extends Product with Serializable

  43. case class OffsetMetadata(offset: Long, metadata: String = OffsetMetadata.NoMetadata) extends Product with Serializable

  44. case class OffsetMetadataAndError(offsetMetadata: OffsetMetadata, error: Short = ...) extends Product with Serializable

  45. class OffsetMetadataTooLargeException extends RuntimeException

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

  46. class OffsetOutOfRangeException extends RuntimeException

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

  47. class OffsetsLoadInProgressException extends RuntimeException

    Indicates that offsets are currently being loaded from disk into the cache so offset fetch requests cannot be satisfied.

  48. class QueueFullException extends RuntimeException

  49. class ReplicaNotAvailableException extends RuntimeException

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

  50. class RequestTimedOutException extends RuntimeException

    Thrown when a produce request times out - i.

  51. class StateChangeFailedException extends RuntimeException

  52. class StreamEndException extends RuntimeException

    An exception that indicates KafkaStream has ended.

  53. class ThreadShutdownException extends RuntimeException

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

  54. class TopicAlreadyMarkedForDeletionException extends RuntimeException

  55. case class TopicAndPartition(topic: String, partition: Int) extends Product with Serializable

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

  56. class TopicAuthorizationException extends AuthorizationException

  57. class TopicExistsException extends RuntimeException

  58. class UnavailableProducerException extends RuntimeException

    Indicates a producer pool initialization problem

  59. class UnknownCodecException extends RuntimeException

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

  60. class UnknownException extends RuntimeException

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

  61. class UnknownMagicByteException extends RuntimeException

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

  62. class UnknownTopicOrPartitionException extends RuntimeException

    Indicates one of the following situation: 1.

  63. class ZkNodeChangeNotificationListener extends Logging

    A listener that subscribes to seqNodeRoot for any child changes where all children are assumed to be sequence node with seqNodePrefix.

Value Members

  1. object AppInfo extends KafkaMetricsGroup

  2. object ErrorMapping

    A bi-directional mapping between error codes and exceptions

  3. object OffsetAndMetadata extends Serializable

  4. object OffsetMetadata extends Serializable

  5. object OffsetMetadataAndError extends Serializable

  6. object Topic

Ungrouped