kafka

common

package common

Visibility
  1. Public
  2. All

Type Members

  1. class AdminCommandFailedException extends RuntimeException

  2. class BrokerNotAvailableException extends RuntimeException

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

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

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

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

  5. trait Config extends Logging

  6. class ConsumerCoordinatorNotAvailableException extends RuntimeException

  7. class ConsumerRebalanceFailedException extends RuntimeException

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

  8. class ControllerMovedException extends RuntimeException

  9. class FailedToSendMessageException extends RuntimeException

    Indicates a producer pool initialization problem

  10. class InvalidConfigException extends RuntimeException

    Indicates that the given config parameter has invalid value

  11. class InvalidMessageSizeException extends RuntimeException

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

  12. class InvalidOffsetException extends RuntimeException

  13. class InvalidTopicException extends RuntimeException

  14. class KafkaException extends RuntimeException

    Generic Kafka exception

  15. class KafkaStorageException extends RuntimeException

    Kafka exception caused by real IOs.

  16. class LeaderElectionNotNeededException extends RuntimeException

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

  17. class LeaderNotAvailableException extends RuntimeException

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

  18. class LogCleaningAbortedException extends RuntimeException

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

  19. class MessageSetSizeTooLargeException extends RuntimeException

  20. class MessageSizeTooLargeException extends RuntimeException

  21. class MessageStreamsExistException extends RuntimeException

    Indicates a createMessageStreams can't be called more thane once

  22. class NoBrokersForPartitionException extends RuntimeException

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

  23. class NoEpochForPartitionException extends RuntimeException

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

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

  25. class NotAssignedReplicaException extends RuntimeException

  26. class NotCoordinatorForConsumerException extends RuntimeException

  27. class NotEnoughReplicasAfterAppendException extends RuntimeException

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

    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.

  28. class NotEnoughReplicasException extends RuntimeException

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

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

  29. class NotLeaderForPartitionException extends RuntimeException

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

  30. case class OffsetAndMetadata(offset: Long, metadata: String = OffsetAndMetadata.NoMetadata, timestamp: Long = 1L) extends Product with Serializable

  31. case class OffsetMetadataAndError(offset: Long, metadata: String = OffsetAndMetadata.NoMetadata, error: Short = ErrorMapping.NoError) extends Product with Serializable

  32. class OffsetMetadataTooLargeException extends RuntimeException

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

  33. class OffsetOutOfRangeException extends RuntimeException

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

  34. class OffsetsLoadInProgressException extends RuntimeException

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

  35. class QueueFullException extends RuntimeException

    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.

  36. class ReplicaNotAvailableException extends RuntimeException

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

  37. class RequestTimedOutException extends RuntimeException

    Thrown when a produce request times out - i.

    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.

  38. class StateChangeFailedException extends RuntimeException

  39. class ThreadShutdownException extends RuntimeException

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

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

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

  41. class TopicExistsException extends RuntimeException

  42. class UnavailableProducerException extends RuntimeException

    Indicates a producer pool initialization problem

  43. class UnknownCodecException extends RuntimeException

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

  44. class UnknownException extends RuntimeException

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

  45. class UnknownMagicByteException extends RuntimeException

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

  46. class UnknownTopicOrPartitionException extends RuntimeException

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

Value Members

  1. object ErrorMapping

    A bi-directional mapping between error codes and exceptions

  2. object OffsetAndMetadata extends Serializable

  3. object OffsetMetadataAndError extends Serializable

  4. object Topic

Ungrouped