Package

kafka

common

Permalink

package common

Visibility
  1. Public
  2. All

Type Members

  1. class AdminCommandFailedException extends RuntimeException

    Permalink
  2. abstract class AuthorizationException extends RuntimeException

    Permalink

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

  3. trait BaseEnum extends Product with Serializable

    Permalink
  4. class BrokerEndPointNotAvailableException extends RuntimeException

    Permalink
  5. class BrokerNotAvailableException extends RuntimeException

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

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

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

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

    Permalink
  10. trait ClientIdBroker extends AnyRef

    Permalink

    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

    Permalink

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

  12. class ClusterAuthorizationException extends AuthorizationException

    Permalink
  13. trait Config extends Logging

    Permalink
  14. class ConsumerCoordinatorNotAvailableException extends RuntimeException

    Permalink
  15. class ConsumerRebalanceFailedException extends RuntimeException

    Permalink

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

  16. class ControllerMovedException extends RuntimeException

    Permalink
  17. class FailedToSendMessageException extends RuntimeException

    Permalink

    Indicates a producer pool initialization problem

  18. class GenerateBrokerIdException extends RuntimeException

    Permalink

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

  19. class GroupAuthorizationException extends AuthorizationException

    Permalink
  20. class InconsistentBrokerIdException extends RuntimeException

    Permalink

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

  21. class InvalidConfigException extends RuntimeException

    Permalink

    Indicates that the given config parameter has invalid value

  22. class InvalidMessageSizeException extends RuntimeException

    Permalink

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

  23. class InvalidOffsetException extends RuntimeException

    Permalink
  24. class InvalidTopicException extends RuntimeException

    Permalink
  25. class KafkaException extends RuntimeException

    Permalink

    Generic Kafka exception

  26. class KafkaStorageException extends RuntimeException

    Permalink

    Kafka exception caused by real IOs.

  27. class LeaderElectionNotNeededException extends RuntimeException

    Permalink

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

  28. class LeaderNotAvailableException extends RuntimeException

    Permalink

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

  29. class LogCleaningAbortedException extends RuntimeException

    Permalink

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

  30. class MessageSetSizeTooLargeException extends RuntimeException

    Permalink
  31. class MessageSizeTooLargeException extends RuntimeException

    Permalink
  32. class MessageStreamsExistException extends RuntimeException

    Permalink

    Indicates a createMessageStreams can't be called more thane once

  33. class NoBrokersForPartitionException extends RuntimeException

    Permalink

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

  34. class NoEpochForPartitionException extends RuntimeException

    Permalink

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

  35. class NoReplicaOnlineException extends RuntimeException

    Permalink

    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

    Permalink
  37. class NotCoordinatorForConsumerException extends RuntimeException

    Permalink
  38. class NotEnoughReplicasAfterAppendException extends RuntimeException

    Permalink

    Number of insync replicas for the partition is lower than min.insync.replicas This exception is raised when the low ISR size is discovered *after* the message was already appended to the log.

    Number of insync replicas for the partition is lower than min.insync.replicas This exception is raised when the low ISR size is discovered *after* the message was already appended to the log. Producer retries will cause duplicates.

  39. class NotEnoughReplicasException extends RuntimeException

    Permalink

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

  40. class NotLeaderForPartitionException extends RuntimeException

    Permalink

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

  41. trait NotificationHandler extends AnyRef

    Permalink

    Handle the notificationMessage.

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

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

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

    Permalink
  45. class OffsetMetadataTooLargeException extends RuntimeException

    Permalink

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

  46. class OffsetOutOfRangeException extends RuntimeException

    Permalink

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

  47. class OffsetsLoadInProgressException extends RuntimeException

    Permalink

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

  48. class QueueFullException extends RuntimeException

    Permalink

    Licensed to the Apache Software Foundation (ASF) under one or more contributor license agreements.

    Licensed to the Apache Software Foundation (ASF) under one or more contributor license agreements. See the NOTICE file distributed with this work for additional information regarding copyright ownership. The ASF licenses this file to You under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with the License. You may obtain a copy of the License at

    http://www.apache.org/licenses/LICENSE-2.0

    Unless required by applicable law or agreed to in writing, software distributed under the License is distributed on an "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the License for the specific language governing permissions and limitations under the License.

  49. class ReplicaNotAvailableException extends RuntimeException

    Permalink

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

  50. class RequestTimedOutException extends RuntimeException

    Permalink

    Thrown when a produce request times out - i.e., if one or more partitions it sends messages to receives fewer than the requiredAcks that is specified in the produce request.

  51. class StateChangeFailedException extends RuntimeException

    Permalink
  52. class StreamEndException extends RuntimeException

    Permalink

    An exception that indicates KafkaStream has ended.

  53. class ThreadShutdownException extends RuntimeException

    Permalink

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

  54. class TopicAlreadyMarkedForDeletionException extends RuntimeException

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

    Permalink

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

  56. class TopicAuthorizationException extends AuthorizationException

    Permalink
  57. class TopicExistsException extends RuntimeException

    Permalink
  58. class UnavailableProducerException extends RuntimeException

    Permalink

    Indicates a producer pool initialization problem

  59. class UnknownCodecException extends RuntimeException

    Permalink

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

  60. class UnknownException extends RuntimeException

    Permalink

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

  61. class UnknownMagicByteException extends RuntimeException

    Permalink

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

  62. class UnknownTopicOrPartitionException extends RuntimeException

    Permalink

    Indicates one of the following situation: 1.

    Indicates one of the following situation: 1. Producer does not have the partition metadata for this id upon sending messages 2. Broker does not have the specified partition by id upon receiving messages

  63. class ZkNodeChangeNotificationListener extends Logging

    Permalink

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

    A listener that subscribes to seqNodeRoot for any child changes where all children are assumed to be sequence node with seqNodePrefix. When a child is added under seqNodeRoot this class gets notified, it looks at lastExecutedChange number to avoid duplicate processing and if it finds an unprocessed child, it reads its data and calls supplied notificationHandler's processNotification() method with the child's data as argument. As part of processing these changes it also purges any children with currentTime - createTime > changeExpirationMs.

    The caller/user of this class should ensure that they use zkClient.subscribeStateChanges and call processAllNotifications method of this class from ZkStateChangeListener's handleNewSession() method. This is necessary to ensure that if zk session is terminated and reestablished any missed notification will be processed immediately.

Value Members

  1. object AppInfo extends KafkaMetricsGroup

    Permalink
  2. object ErrorMapping

    Permalink

    A bi-directional mapping between error codes and exceptions

  3. object OffsetAndMetadata extends Serializable

    Permalink
  4. object OffsetMetadata extends Serializable

    Permalink
  5. object OffsetMetadataAndError extends Serializable

    Permalink
  6. object Topic

    Permalink

Ungrouped