Exception thrown when a principal is not authorized to perform an operation.
Convenience case class since (clientId, brokerInfo) pairs are used to create SyncProducer Request Stats and SimpleConsumer Request and Response Stats.
Convenience case class since (clientId, topic) pairs are used in the creation of many Stats objects.
Thrown when a request is made for broker but no brokers with that topic exist.
Indicates a producer pool initialization problem
Thrown when there is a failure to generate a zookeeper sequenceId to use as brokerId
Indicates the brokerId stored in logDirs is not consistent across logDirs.
Indicates that the given config parameter has invalid value
Indicates the client has requested a range no longer available on the server
Generic Kafka exception
Kafka exception caused by real IOs.
This exception is thrown when new leader election is not necessary.
Thrown when a request is made for partition, but no leader exists for that partition
Thrown when a log cleaning task is requested to be aborted.
Indicates a createMessageStreams can't be called more thane once
Thrown when a request is made for broker but no brokers with that topic exist.
Thrown when a get epoch request is made for partition, but no epoch exists for that partition
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.
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.
Message was rejected because number of insync replicas for the partition is lower than min.insync.replicas
Thrown when a request is made for partition on a broker that is NOT a leader for that partition
Handle the notificationMessage.
Indicates the client has specified offset metadata that exceeds the configured maximum size in bytes
Indicates the client has requested a range no longer available on the server
Indicates that offsets are currently being loaded from disk into the cache so offset fetch requests cannot be satisfied.
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.
Thrown when a request is made for partition, but no leader exists for that partition
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.
An exception that indicates KafkaStream has ended.
An exception that indicates a thread is being shut down normally.
Convenience case class since (topic, partition) pairs are ubiquitous.
Indicates a producer pool initialization problem
Indicates the client has requested a range no longer available on the server
If we don't know what else it is, call it this
Indicates the client has requested a range no longer available on the server
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
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.
A bi-directional mapping between error codes and exceptions
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.