A B C D E F G H I K L M N O P R S T U V W 

A

ACKS_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
acks
addDeserializerToConfig(Map<String, Object>, Deserializer<?>, Deserializer<?>) - Static method in class org.apache.kafka.clients.consumer.ConsumerConfig
 
addDeserializerToConfig(Properties, Deserializer<?>, Deserializer<?>) - Static method in class org.apache.kafka.clients.consumer.ConsumerConfig
 
addRecord(ConsumerRecord<K, V>) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
addSerializerToConfig(Map<String, Object>, Serializer<?>, Serializer<?>) - Static method in class org.apache.kafka.clients.producer.ProducerConfig
 
addSerializerToConfig(Properties, Serializer<?>, Serializer<?>) - Static method in class org.apache.kafka.clients.producer.ProducerConfig
 
allPartitionsSorted(Map<String, Integer>, Map<String, List<String>>) - Method in class org.apache.kafka.clients.consumer.RoundRobinAssignor
 
ApiException - Exception in org.apache.kafka.common.errors
Any API exception that is part of the public protocol and should be a subclass of this class and be part of this package.
ApiException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.ApiException
 
ApiException(String) - Constructor for exception org.apache.kafka.common.errors.ApiException
 
ApiException(Throwable) - Constructor for exception org.apache.kafka.common.errors.ApiException
 
ApiException() - Constructor for exception org.apache.kafka.common.errors.ApiException
 
assign(List<TopicPartition>) - Method in interface org.apache.kafka.clients.consumer.Consumer
 
assign(List<TopicPartition>) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Manually assign a list of partition to this consumer.
assign(List<TopicPartition>) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
assign(Map<String, Integer>, Map<String, List<String>>) - Method in class org.apache.kafka.clients.consumer.RangeAssignor
 
assign(Map<String, Integer>, Map<String, List<String>>) - Method in class org.apache.kafka.clients.consumer.RoundRobinAssignor
 
assignment() - Method in interface org.apache.kafka.clients.consumer.Consumer
 
assignment() - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Get the set of partitions currently assigned to this consumer.
assignment() - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
AuthorizationException - Exception in org.apache.kafka.common.errors
 
AuthorizationException(String) - Constructor for exception org.apache.kafka.common.errors.AuthorizationException
 
AUTO_COMMIT_INTERVAL_MS_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
auto.commit.interval.ms
AUTO_OFFSET_RESET_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
auto.offset.reset
availablePartitionsForTopic(String) - Method in class org.apache.kafka.common.Cluster
Get the list of available partitions for this topic

B

BATCH_SIZE_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
batch.size
BLOCK_ON_BUFFER_FULL_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
Deprecated.
This config will be removed in a future release. Also, the ProducerConfig.METADATA_FETCH_TIMEOUT_CONFIG is no longer honored when this property is set to true.
bootstrap(List<InetSocketAddress>) - Static method in class org.apache.kafka.common.Cluster
Create a "bootstrap" cluster using the given list of host/ports
BOOTSTRAP_SERVERS_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
bootstrap.servers
BOOTSTRAP_SERVERS_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
bootstrap.servers
BrokerNotAvailableException - Exception in org.apache.kafka.common.errors
 
BrokerNotAvailableException(String) - Constructor for exception org.apache.kafka.common.errors.BrokerNotAvailableException
 
BrokerNotAvailableException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.BrokerNotAvailableException
 
BUFFER_MEMORY_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
buffer.memory
BufferExhaustedException - Exception in org.apache.kafka.clients.producer
This exception is thrown if the producer is in non-blocking mode and the rate of data production exceeds the rate at which data can be sent for long enough for the alloted buffer to be exhausted.
BufferExhaustedException(String) - Constructor for exception org.apache.kafka.clients.producer.BufferExhaustedException
 
ByteArrayDeserializer - Class in org.apache.kafka.common.serialization
 
ByteArrayDeserializer() - Constructor for class org.apache.kafka.common.serialization.ByteArrayDeserializer
 
ByteArraySerializer - Class in org.apache.kafka.common.serialization
 
ByteArraySerializer() - Constructor for class org.apache.kafka.common.serialization.ByteArraySerializer
 

C

Callback - Interface in org.apache.kafka.clients.producer
A callback interface that the user can implement to allow code to execute when the request is complete.
CHECK_CRCS_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
check.crcs
clear() - Method in class org.apache.kafka.clients.producer.MockProducer
Clear the stored history of sent records
CLIENT_ID_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
client.id
CLIENT_ID_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
client.id
close() - Method in interface org.apache.kafka.clients.consumer.Consumer
 
close() - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Close the consumer, waiting indefinitely for any needed cleanup.
close() - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
close() - Method in class org.apache.kafka.clients.producer.KafkaProducer
Close this producer.
close(long, TimeUnit) - Method in class org.apache.kafka.clients.producer.KafkaProducer
This method waits up to timeout for the producer to complete the sending of all incomplete requests.
close() - Method in class org.apache.kafka.clients.producer.MockProducer
 
close(long, TimeUnit) - Method in class org.apache.kafka.clients.producer.MockProducer
 
close() - Method in interface org.apache.kafka.clients.producer.Partitioner
This is called when partitioner is closed.
close() - Method in interface org.apache.kafka.clients.producer.Producer
Close this producer
close(long, TimeUnit) - Method in interface org.apache.kafka.clients.producer.Producer
Tries to close the producer cleanly within the specified timeout.
close() - Method in class org.apache.kafka.common.serialization.ByteArrayDeserializer
 
close() - Method in class org.apache.kafka.common.serialization.ByteArraySerializer
 
close() - Method in interface org.apache.kafka.common.serialization.Deserializer
 
close() - Method in class org.apache.kafka.common.serialization.IntegerDeserializer
 
close() - Method in class org.apache.kafka.common.serialization.IntegerSerializer
 
close() - Method in class org.apache.kafka.common.serialization.LongDeserializer
 
close() - Method in class org.apache.kafka.common.serialization.LongSerializer
 
close() - Method in interface org.apache.kafka.common.serialization.Serializer
Close this serializer.
close() - Method in class org.apache.kafka.common.serialization.StringDeserializer
 
close() - Method in class org.apache.kafka.common.serialization.StringSerializer
 
closed() - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
Cluster - Class in org.apache.kafka.common
A representation of a subset of the nodes, topics, and partitions in the Kafka cluster.
Cluster(Collection<Node>, Collection<PartitionInfo>, Set<String>) - Constructor for class org.apache.kafka.common.Cluster
Create a new cluster with the given nodes and partitions
commitAsync() - Method in interface org.apache.kafka.clients.consumer.Consumer
 
commitAsync(OffsetCommitCallback) - Method in interface org.apache.kafka.clients.consumer.Consumer
 
commitAsync(Map<TopicPartition, OffsetAndMetadata>, OffsetCommitCallback) - Method in interface org.apache.kafka.clients.consumer.Consumer
 
commitAsync() - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Commit offsets returned on the last poll() for all the subscribed list of topics and partition.
commitAsync(OffsetCommitCallback) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Commit offsets returned on the last poll() for the subscribed list of topics and partitions.
commitAsync(Map<TopicPartition, OffsetAndMetadata>, OffsetCommitCallback) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Commit the specified offsets for the specified list of topics and partitions to Kafka.
commitAsync(Map<TopicPartition, OffsetAndMetadata>, OffsetCommitCallback) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
commitAsync() - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
commitAsync(OffsetCommitCallback) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
CommitFailedException - Exception in org.apache.kafka.clients.consumer
This exception is raised when an offset commit with KafkaConsumer.commitSync() fails with an unrecoverable error.
CommitFailedException(String) - Constructor for exception org.apache.kafka.clients.consumer.CommitFailedException
 
commitSync() - Method in interface org.apache.kafka.clients.consumer.Consumer
 
commitSync(Map<TopicPartition, OffsetAndMetadata>) - Method in interface org.apache.kafka.clients.consumer.Consumer
 
commitSync() - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Commit offsets returned on the last poll() for all the subscribed list of topics and partitions.
commitSync(Map<TopicPartition, OffsetAndMetadata>) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Commit the specified offsets for the specified list of topics and partitions.
commitSync(Map<TopicPartition, OffsetAndMetadata>) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
commitSync() - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
committed(TopicPartition) - Method in interface org.apache.kafka.clients.consumer.Consumer
 
committed(TopicPartition) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Get the last committed offset for the given partition (whether the commit happened by this process or another).
committed(TopicPartition) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
completeNext() - Method in class org.apache.kafka.clients.producer.MockProducer
Complete the earliest uncompleted call successfully.
COMPRESSION_TYPE_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
compression.type
Configurable - Interface in org.apache.kafka.common
A Mix-in style interface for classes that are instantiated by reflection and need to take configuration parameters
configure(Map<String, ?>) - Method in interface org.apache.kafka.common.Configurable
Configure this class with the given key-value pairs
configure(Map<String, ?>, boolean) - Method in class org.apache.kafka.common.serialization.ByteArrayDeserializer
 
configure(Map<String, ?>, boolean) - Method in class org.apache.kafka.common.serialization.ByteArraySerializer
 
configure(Map<String, ?>, boolean) - Method in interface org.apache.kafka.common.serialization.Deserializer
Configure this class.
configure(Map<String, ?>, boolean) - Method in class org.apache.kafka.common.serialization.IntegerDeserializer
 
configure(Map<String, ?>, boolean) - Method in class org.apache.kafka.common.serialization.IntegerSerializer
 
configure(Map<String, ?>, boolean) - Method in class org.apache.kafka.common.serialization.LongDeserializer
 
configure(Map<String, ?>, boolean) - Method in class org.apache.kafka.common.serialization.LongSerializer
 
configure(Map<String, ?>, boolean) - Method in interface org.apache.kafka.common.serialization.Serializer
Configure this class.
configure(Map<String, ?>, boolean) - Method in class org.apache.kafka.common.serialization.StringDeserializer
 
configure(Map<String, ?>, boolean) - Method in class org.apache.kafka.common.serialization.StringSerializer
 
CONNECTIONS_MAX_IDLE_MS_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
connections.max.idle.ms
CONNECTIONS_MAX_IDLE_MS_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
connections.max.idle.ms
Consumer<K,V> - Interface in org.apache.kafka.clients.consumer
 
ConsumerConfig - Class in org.apache.kafka.clients.consumer
The consumer configuration keys
ConsumerRebalanceListener - Interface in org.apache.kafka.clients.consumer
A callback interface that the user can implement to trigger custom actions when the set of partitions assigned to the consumer changes.
ConsumerRecord<K,V> - Class in org.apache.kafka.clients.consumer
A key/value pair to be received from Kafka.
ConsumerRecord(String, int, long, K, V) - Constructor for class org.apache.kafka.clients.consumer.ConsumerRecord
Creates a record to be received from a specified topic and partition
ConsumerRecords<K,V> - Class in org.apache.kafka.clients.consumer
A container that holds the list ConsumerRecord per partition for a particular topic.
ConsumerRecords(Map<TopicPartition, List<ConsumerRecord<K, V>>>) - Constructor for class org.apache.kafka.clients.consumer.ConsumerRecords
 
ControllerMovedException - Exception in org.apache.kafka.common.errors
 
ControllerMovedException(String) - Constructor for exception org.apache.kafka.common.errors.ControllerMovedException
 
ControllerMovedException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.ControllerMovedException
 
CorruptRecordException - Exception in org.apache.kafka.common.errors
This exception indicates a record has failed its internal CRC check, this generally indicates network or disk corruption.
CorruptRecordException() - Constructor for exception org.apache.kafka.common.errors.CorruptRecordException
 
CorruptRecordException(String) - Constructor for exception org.apache.kafka.common.errors.CorruptRecordException
 
CorruptRecordException(Throwable) - Constructor for exception org.apache.kafka.common.errors.CorruptRecordException
 
CorruptRecordException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.CorruptRecordException
 
count() - Method in class org.apache.kafka.clients.consumer.ConsumerRecords
The number of records for all topics

D

description() - Method in class org.apache.kafka.common.MetricName
 
deserialize(String, byte[]) - Method in class org.apache.kafka.common.serialization.ByteArrayDeserializer
 
deserialize(String, byte[]) - Method in interface org.apache.kafka.common.serialization.Deserializer
 
deserialize(String, byte[]) - Method in class org.apache.kafka.common.serialization.IntegerDeserializer
 
deserialize(String, byte[]) - Method in class org.apache.kafka.common.serialization.LongDeserializer
 
deserialize(String, byte[]) - Method in class org.apache.kafka.common.serialization.StringDeserializer
 
Deserializer<T> - Interface in org.apache.kafka.common.serialization
 
DisconnectException - Exception in org.apache.kafka.common.errors
Server disconnected before a request could be completed.
DisconnectException() - Constructor for exception org.apache.kafka.common.errors.DisconnectException
 
DisconnectException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.DisconnectException
 
DisconnectException(String) - Constructor for exception org.apache.kafka.common.errors.DisconnectException
 
DisconnectException(Throwable) - Constructor for exception org.apache.kafka.common.errors.DisconnectException
 

E

EMPTY - Static variable in class org.apache.kafka.clients.consumer.ConsumerRecords
 
empty() - Static method in class org.apache.kafka.clients.consumer.ConsumerRecords
 
empty() - Static method in class org.apache.kafka.common.Cluster
Create an empty cluster instance with no nodes and no topic-partitions.
ENABLE_AUTO_COMMIT_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
enable.auto.commit
equals(Object) - Method in class org.apache.kafka.clients.consumer.OffsetAndMetadata
 
equals(Object) - Method in class org.apache.kafka.clients.producer.ProducerRecord
 
equals(Object) - Method in class org.apache.kafka.common.MetricName
 
equals(Object) - Method in class org.apache.kafka.common.Node
 
equals(Object) - Method in class org.apache.kafka.common.TopicPartition
 
errorNext(RuntimeException) - Method in class org.apache.kafka.clients.producer.MockProducer
Complete the earliest uncompleted call with the given error.

F

FETCH_MAX_WAIT_MS_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
fetch.max.wait.ms
FETCH_MIN_BYTES_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
fetch.min.bytes
fillInStackTrace() - Method in exception org.apache.kafka.common.errors.ApiException
 
fillInStackTrace() - Method in exception org.apache.kafka.common.errors.SerializationException
 
flush() - Method in class org.apache.kafka.clients.producer.KafkaProducer
Invoking this method makes all buffered records immediately available to send (even if linger.ms is greater than 0) and blocks on the completion of the requests associated with these records.
flush() - Method in class org.apache.kafka.clients.producer.MockProducer
 
flush() - Method in interface org.apache.kafka.clients.producer.Producer
Flush any accumulated records from the producer.

G

group() - Method in class org.apache.kafka.common.MetricName
 
GROUP_ID_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
group.id
GroupAuthorizationException - Exception in org.apache.kafka.common.errors
 
GroupAuthorizationException(String) - Constructor for exception org.apache.kafka.common.errors.GroupAuthorizationException
 
GroupCoordinatorNotAvailableException - Exception in org.apache.kafka.common.errors
The broker returns this error code for consumer metadata requests or offset commit requests if the offsets topic has not yet been created.
GroupCoordinatorNotAvailableException() - Constructor for exception org.apache.kafka.common.errors.GroupCoordinatorNotAvailableException
 
GroupCoordinatorNotAvailableException(String) - Constructor for exception org.apache.kafka.common.errors.GroupCoordinatorNotAvailableException
 
GroupCoordinatorNotAvailableException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.GroupCoordinatorNotAvailableException
 
GroupCoordinatorNotAvailableException(Throwable) - Constructor for exception org.apache.kafka.common.errors.GroupCoordinatorNotAvailableException
 
groupId() - Method in exception org.apache.kafka.common.errors.GroupAuthorizationException
 
GroupLoadInProgressException - Exception in org.apache.kafka.common.errors
The broker returns this error code for any coordiantor request if it is still loading the metadata (after a leader change for that offsets topic partition) for this group.
GroupLoadInProgressException() - Constructor for exception org.apache.kafka.common.errors.GroupLoadInProgressException
 
GroupLoadInProgressException(String) - Constructor for exception org.apache.kafka.common.errors.GroupLoadInProgressException
 
GroupLoadInProgressException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.GroupLoadInProgressException
 
GroupLoadInProgressException(Throwable) - Constructor for exception org.apache.kafka.common.errors.GroupLoadInProgressException
 

H

hashCode() - Method in class org.apache.kafka.clients.consumer.OffsetAndMetadata
 
hashCode() - Method in class org.apache.kafka.clients.producer.ProducerRecord
 
hashCode() - Method in class org.apache.kafka.common.MetricName
 
hashCode() - Method in class org.apache.kafka.common.Node
 
hashCode() - Method in class org.apache.kafka.common.TopicPartition
 
HEARTBEAT_INTERVAL_MS_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
heartbeat.interval.ms
history() - Method in class org.apache.kafka.clients.producer.MockProducer
Get the list of sent records since the last call to MockProducer.clear()
host() - Method in class org.apache.kafka.common.Node
The host name for this node

I

id() - Method in class org.apache.kafka.common.Node
The node id of this node
idString() - Method in class org.apache.kafka.common.Node
String representation of the node id.
IllegalGenerationException - Exception in org.apache.kafka.common.errors
 
IllegalGenerationException() - Constructor for exception org.apache.kafka.common.errors.IllegalGenerationException
 
IllegalGenerationException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.IllegalGenerationException
 
IllegalGenerationException(String) - Constructor for exception org.apache.kafka.common.errors.IllegalGenerationException
 
IllegalGenerationException(Throwable) - Constructor for exception org.apache.kafka.common.errors.IllegalGenerationException
 
INSTANCE - Static variable in exception org.apache.kafka.common.errors.DisconnectException
 
inSyncReplicas() - Method in class org.apache.kafka.common.PartitionInfo
The subset of the replicas that are in sync, that is caught-up to the leader and ready to take over as leader if the leader should fail
IntegerDeserializer - Class in org.apache.kafka.common.serialization
 
IntegerDeserializer() - Constructor for class org.apache.kafka.common.serialization.IntegerDeserializer
 
IntegerSerializer - Class in org.apache.kafka.common.serialization
 
IntegerSerializer() - Constructor for class org.apache.kafka.common.serialization.IntegerSerializer
 
InterruptException - Exception in org.apache.kafka.common.errors
An unchecked wrapper for InterruptedException
InterruptException(InterruptedException) - Constructor for exception org.apache.kafka.common.errors.InterruptException
 
InterruptException(String, InterruptedException) - Constructor for exception org.apache.kafka.common.errors.InterruptException
 
InterruptException(String) - Constructor for exception org.apache.kafka.common.errors.InterruptException
 
InvalidMetadataException - Exception in org.apache.kafka.common.errors
An exception that may indicate the client's metadata is out of date
InvalidMetadataException() - Constructor for exception org.apache.kafka.common.errors.InvalidMetadataException
 
InvalidMetadataException(String) - Constructor for exception org.apache.kafka.common.errors.InvalidMetadataException
 
InvalidMetadataException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.InvalidMetadataException
 
InvalidMetadataException(Throwable) - Constructor for exception org.apache.kafka.common.errors.InvalidMetadataException
 
InvalidOffsetException - Exception in org.apache.kafka.clients.consumer
Thrown when the offset for a set of partitions is invalid (either undefined or out of range), and no reset policy has been configured.
InvalidOffsetException(String) - Constructor for exception org.apache.kafka.clients.consumer.InvalidOffsetException
 
InvalidRequiredAcksException - Exception in org.apache.kafka.common.errors
 
InvalidRequiredAcksException(String) - Constructor for exception org.apache.kafka.common.errors.InvalidRequiredAcksException
 
InvalidTopicException - Exception in org.apache.kafka.common.errors
The client has attempted to perform an operation on an invalid topic.
InvalidTopicException() - Constructor for exception org.apache.kafka.common.errors.InvalidTopicException
 
InvalidTopicException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.InvalidTopicException
 
InvalidTopicException(String) - Constructor for exception org.apache.kafka.common.errors.InvalidTopicException
 
InvalidTopicException(Throwable) - Constructor for exception org.apache.kafka.common.errors.InvalidTopicException
 
isEmpty() - Method in class org.apache.kafka.clients.consumer.ConsumerRecords
 
iterator() - Method in class org.apache.kafka.clients.consumer.ConsumerRecords
 

K

KafkaConsumer<K,V> - Class in org.apache.kafka.clients.consumer
A Kafka client that consumes records from a Kafka cluster.
KafkaConsumer(Map<String, Object>) - Constructor for class org.apache.kafka.clients.consumer.KafkaConsumer
A consumer is instantiated by providing a set of key-value pairs as configuration.
KafkaConsumer(Map<String, Object>, Deserializer<K>, Deserializer<V>) - Constructor for class org.apache.kafka.clients.consumer.KafkaConsumer
A consumer is instantiated by providing a set of key-value pairs as configuration, a ConsumerRebalanceListener implementation, a key and a value Deserializer.
KafkaConsumer(Properties) - Constructor for class org.apache.kafka.clients.consumer.KafkaConsumer
A consumer is instantiated by providing a Properties object as configuration.
KafkaConsumer(Properties, Deserializer<K>, Deserializer<V>) - Constructor for class org.apache.kafka.clients.consumer.KafkaConsumer
A consumer is instantiated by providing a Properties object as configuration and a ConsumerRebalanceListener implementation, a key and a value Deserializer.
KafkaException - Exception in org.apache.kafka.common
The base class of all other Kafka exceptions
KafkaException(String, Throwable) - Constructor for exception org.apache.kafka.common.KafkaException
 
KafkaException(String) - Constructor for exception org.apache.kafka.common.KafkaException
 
KafkaException(Throwable) - Constructor for exception org.apache.kafka.common.KafkaException
 
KafkaException() - Constructor for exception org.apache.kafka.common.KafkaException
 
KafkaProducer<K,V> - Class in org.apache.kafka.clients.producer
A Kafka client that publishes records to the Kafka cluster.
KafkaProducer(Map<String, Object>) - Constructor for class org.apache.kafka.clients.producer.KafkaProducer
A producer is instantiated by providing a set of key-value pairs as configuration.
KafkaProducer(Map<String, Object>, Serializer<K>, Serializer<V>) - Constructor for class org.apache.kafka.clients.producer.KafkaProducer
A producer is instantiated by providing a set of key-value pairs as configuration, a key and a value Serializer.
KafkaProducer(Properties) - Constructor for class org.apache.kafka.clients.producer.KafkaProducer
A producer is instantiated by providing a set of key-value pairs as configuration.
KafkaProducer(Properties, Serializer<K>, Serializer<V>) - Constructor for class org.apache.kafka.clients.producer.KafkaProducer
A producer is instantiated by providing a set of key-value pairs as configuration, a key and a value Serializer.
key() - Method in class org.apache.kafka.clients.consumer.ConsumerRecord
The key (or null if no key is specified)
key() - Method in class org.apache.kafka.clients.producer.ProducerRecord
The key (or null if no key is specified)
KEY_DESERIALIZER_CLASS_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
key.deserializer
KEY_DESERIALIZER_CLASS_DOC - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
 
KEY_SERIALIZER_CLASS_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
key.serializer
KEY_SERIALIZER_CLASS_DOC - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
 

L

leader() - Method in class org.apache.kafka.common.PartitionInfo
The node id of the node currently acting as a leader for this partition or -1 if there is no leader
leaderFor(TopicPartition) - Method in class org.apache.kafka.common.Cluster
Get the current leader for the given topic-partition
LeaderNotAvailableException - Exception in org.apache.kafka.common.errors
There is no currently available leader for the given partition (either because a leadership election is in progress or because all replicas are down).
LeaderNotAvailableException(String) - Constructor for exception org.apache.kafka.common.errors.LeaderNotAvailableException
 
LINGER_MS_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
linger.ms
listTopics() - Method in interface org.apache.kafka.clients.consumer.Consumer
 
listTopics() - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Get metadata about partitions for all topics that the user is authorized to view.
listTopics() - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
LongDeserializer - Class in org.apache.kafka.common.serialization
 
LongDeserializer() - Constructor for class org.apache.kafka.common.serialization.LongDeserializer
 
LongSerializer - Class in org.apache.kafka.common.serialization
 
LongSerializer() - Constructor for class org.apache.kafka.common.serialization.LongSerializer
 

M

main(String[]) - Static method in class org.apache.kafka.clients.consumer.ConsumerConfig
 
main(String[]) - Static method in class org.apache.kafka.clients.producer.ProducerConfig
 
MAX_BLOCK_MS_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
max.block.ms
MAX_IN_FLIGHT_REQUESTS_PER_CONNECTION - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
max.in.flight.requests.per.connection
MAX_PARTITION_FETCH_BYTES_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
max.partition.fetch.bytes
MAX_REQUEST_SIZE_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
max.request.size
metadata() - Method in class org.apache.kafka.clients.consumer.OffsetAndMetadata
 
METADATA_FETCH_TIMEOUT_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
Deprecated.
This config will be removed in a future release. Please use ProducerConfig.MAX_BLOCK_MS_CONFIG
METADATA_MAX_AGE_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
metadata.max.age.ms
METADATA_MAX_AGE_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
metadata.max.age.ms
Metric - Interface in org.apache.kafka.common
A numerical metric tracked for monitoring purposes
METRIC_REPORTER_CLASSES_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
metric.reporters
METRIC_REPORTER_CLASSES_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
metric.reporters
metricName() - Method in interface org.apache.kafka.common.Metric
A name for this metric
MetricName - Class in org.apache.kafka.common
The MetricName class encapsulates a metric's name, logical group and its related attributes
MetricName(String, String, String, Map<String, String>) - Constructor for class org.apache.kafka.common.MetricName
 
MetricName(String, String, String, String...) - Constructor for class org.apache.kafka.common.MetricName
 
MetricName(String, String, Map<String, String>) - Constructor for class org.apache.kafka.common.MetricName
 
MetricName(String, String, String) - Constructor for class org.apache.kafka.common.MetricName
 
MetricName(String, String) - Constructor for class org.apache.kafka.common.MetricName
 
metrics() - Method in interface org.apache.kafka.clients.consumer.Consumer
 
metrics() - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Get the metrics kept by the consumer
metrics() - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
metrics() - Method in class org.apache.kafka.clients.producer.KafkaProducer
Get the full set of internal metrics maintained by the producer.
metrics() - Method in class org.apache.kafka.clients.producer.MockProducer
 
metrics() - Method in interface org.apache.kafka.clients.producer.Producer
Return a map of metrics maintained by the producer
METRICS_NUM_SAMPLES_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
metrics.num.samples
METRICS_NUM_SAMPLES_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
metrics.num.samples
METRICS_SAMPLE_WINDOW_MS_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
metrics.sample.window.ms
METRICS_SAMPLE_WINDOW_MS_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
metrics.sample.window.ms
MockConsumer<K,V> - Class in org.apache.kafka.clients.consumer
A mock of the Consumer interface you can use for testing code that uses Kafka.
MockConsumer(OffsetResetStrategy) - Constructor for class org.apache.kafka.clients.consumer.MockConsumer
 
MockProducer<K,V> - Class in org.apache.kafka.clients.producer
A mock of the producer interface you can use for testing code that uses Kafka.
MockProducer(Cluster, boolean, Partitioner, Serializer<K>, Serializer<V>) - Constructor for class org.apache.kafka.clients.producer.MockProducer
Create a mock producer
MockProducer(boolean, Serializer<K>, Serializer<V>) - Constructor for class org.apache.kafka.clients.producer.MockProducer
Create a new mock producer with invented metadata the given autoComplete setting and key\value serializers Equivalent to MockProducer.MockProducer(Cluster, boolean, Partitioner, Serializer, Serializer) new MockProducer(Cluster.empty(), autoComplete, new DefaultPartitioner(), keySerializer, valueSerializer)}
MockProducer(boolean, Partitioner, Serializer<K>, Serializer<V>) - Constructor for class org.apache.kafka.clients.producer.MockProducer
Create a new mock producer with invented metadata the given autoComplete setting, partitioner and key\value serializers Equivalent to MockProducer.MockProducer(Cluster, boolean, Partitioner, Serializer, Serializer) new MockProducer(Cluster.empty(), autoComplete, partitioner, keySerializer, valueSerializer)}

N

name() - Method in class org.apache.kafka.clients.consumer.RangeAssignor
 
name() - Method in class org.apache.kafka.clients.consumer.RoundRobinAssignor
 
name() - Method in class org.apache.kafka.common.MetricName
 
NetworkException - Exception in org.apache.kafka.common.errors
A misc.
NetworkException() - Constructor for exception org.apache.kafka.common.errors.NetworkException
 
NetworkException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.NetworkException
 
NetworkException(String) - Constructor for exception org.apache.kafka.common.errors.NetworkException
 
NetworkException(Throwable) - Constructor for exception org.apache.kafka.common.errors.NetworkException
 
Node - Class in org.apache.kafka.common
Information about a Kafka node
Node(int, String, int) - Constructor for class org.apache.kafka.common.Node
 
nodeById(int) - Method in class org.apache.kafka.common.Cluster
Get the node by the node id (or null if no such node exists)
nodes() - Method in class org.apache.kafka.common.Cluster
 
noNode() - Static method in class org.apache.kafka.common.Node
 
NoOffsetForPartitionException - Exception in org.apache.kafka.clients.consumer
Indicates that there is no stored offset for a partition and no defined offset reset policy.
NoOffsetForPartitionException(TopicPartition) - Constructor for exception org.apache.kafka.clients.consumer.NoOffsetForPartitionException
 
NotCoordinatorForGroupException - Exception in org.apache.kafka.common.errors
The broker returns this error code if it receives an offset fetch or commit request for a consumer group that it is not a coordinator for.
NotCoordinatorForGroupException() - Constructor for exception org.apache.kafka.common.errors.NotCoordinatorForGroupException
 
NotCoordinatorForGroupException(String) - Constructor for exception org.apache.kafka.common.errors.NotCoordinatorForGroupException
 
NotCoordinatorForGroupException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.NotCoordinatorForGroupException
 
NotCoordinatorForGroupException(Throwable) - Constructor for exception org.apache.kafka.common.errors.NotCoordinatorForGroupException
 
NotEnoughReplicasAfterAppendException - Exception in org.apache.kafka.common.errors
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.
NotEnoughReplicasAfterAppendException(String) - Constructor for exception org.apache.kafka.common.errors.NotEnoughReplicasAfterAppendException
 
NotEnoughReplicasException - Exception in org.apache.kafka.common.errors
Number of insync replicas for the partition is lower than min.insync.replicas
NotEnoughReplicasException() - Constructor for exception org.apache.kafka.common.errors.NotEnoughReplicasException
 
NotEnoughReplicasException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.NotEnoughReplicasException
 
NotEnoughReplicasException(String) - Constructor for exception org.apache.kafka.common.errors.NotEnoughReplicasException
 
NotEnoughReplicasException(Throwable) - Constructor for exception org.apache.kafka.common.errors.NotEnoughReplicasException
 
NotLeaderForPartitionException - Exception in org.apache.kafka.common.errors
This server is not the leader for the given partition
NotLeaderForPartitionException() - Constructor for exception org.apache.kafka.common.errors.NotLeaderForPartitionException
 
NotLeaderForPartitionException(String) - Constructor for exception org.apache.kafka.common.errors.NotLeaderForPartitionException
 
NotLeaderForPartitionException(Throwable) - Constructor for exception org.apache.kafka.common.errors.NotLeaderForPartitionException
 
NotLeaderForPartitionException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.NotLeaderForPartitionException
 

O

offset() - Method in class org.apache.kafka.clients.consumer.ConsumerRecord
The position of this record in the corresponding Kafka partition.
offset() - Method in class org.apache.kafka.clients.consumer.OffsetAndMetadata
 
offset() - Method in class org.apache.kafka.clients.producer.RecordMetadata
The offset of the record in the topic/partition.
OffsetAndMetadata - Class in org.apache.kafka.clients.consumer
The Kafka offset commit API allows users to provide additional metadata (in the form of a string) when an offset is committed.
OffsetAndMetadata(long, String) - Constructor for class org.apache.kafka.clients.consumer.OffsetAndMetadata
Construct a new OffsetAndMetadata object for committing through KafkaConsumer.
OffsetAndMetadata(long) - Constructor for class org.apache.kafka.clients.consumer.OffsetAndMetadata
Construct a new OffsetAndMetadata object for committing through KafkaConsumer.
OffsetCommitCallback - Interface in org.apache.kafka.clients.consumer
A callback interface that the user can implement to trigger custom actions when a commit request completes.
OffsetMetadataTooLarge - Exception in org.apache.kafka.common.errors
The client has tried to save its offset with associated metadata larger than the maximum size allowed by the server.
OffsetMetadataTooLarge() - Constructor for exception org.apache.kafka.common.errors.OffsetMetadataTooLarge
 
OffsetMetadataTooLarge(String) - Constructor for exception org.apache.kafka.common.errors.OffsetMetadataTooLarge
 
OffsetMetadataTooLarge(Throwable) - Constructor for exception org.apache.kafka.common.errors.OffsetMetadataTooLarge
 
OffsetMetadataTooLarge(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.OffsetMetadataTooLarge
 
OffsetOutOfRangeException - Exception in org.apache.kafka.clients.consumer
No reset policy has been defined, and the offsets for these partitions are either larger or smaller than the range of offsets the server has for the given partition.
OffsetOutOfRangeException(Map<TopicPartition, Long>) - Constructor for exception org.apache.kafka.clients.consumer.OffsetOutOfRangeException
 
offsetOutOfRangePartitions() - Method in exception org.apache.kafka.clients.consumer.OffsetOutOfRangeException
 
OffsetResetStrategy - Enum in org.apache.kafka.clients.consumer
 
onComplete(Map<TopicPartition, OffsetAndMetadata>, Exception) - Method in interface org.apache.kafka.clients.consumer.OffsetCommitCallback
A callback method the user can implement to provide asynchronous handling of commit request completion.
onCompletion(RecordMetadata, Exception) - Method in interface org.apache.kafka.clients.producer.Callback
A callback method the user can implement to provide asynchronous handling of request completion.
onPartitionsAssigned(Collection<TopicPartition>) - Method in interface org.apache.kafka.clients.consumer.ConsumerRebalanceListener
A callback method the user can implement to provide handling of customized offsets on completion of a successful partition re-assignment.
onPartitionsRevoked(Collection<TopicPartition>) - Method in interface org.apache.kafka.clients.consumer.ConsumerRebalanceListener
A callback method the user can implement to provide handling of offset commits to a customized store on the start of a rebalance operation.
org.apache.kafka.clients.consumer - package org.apache.kafka.clients.consumer
 
org.apache.kafka.clients.producer - package org.apache.kafka.clients.producer
 
org.apache.kafka.common - package org.apache.kafka.common
 
org.apache.kafka.common.errors - package org.apache.kafka.common.errors
 
org.apache.kafka.common.serialization - package org.apache.kafka.common.serialization
 

P

partition() - Method in class org.apache.kafka.clients.consumer.ConsumerRecord
The partition from which this record is received
partition() - Method in exception org.apache.kafka.clients.consumer.NoOffsetForPartitionException
 
partition(String, Object, byte[], Object, byte[], Cluster) - Method in interface org.apache.kafka.clients.producer.Partitioner
Compute the partition for the given record.
partition() - Method in class org.apache.kafka.clients.producer.ProducerRecord
The partition to which the record will be sent (or null if no partition was specified)
partition() - Method in class org.apache.kafka.clients.producer.RecordMetadata
The partition the record was sent to
partition(TopicPartition) - Method in class org.apache.kafka.common.Cluster
Get the metadata for the specified partition
partition() - Method in class org.apache.kafka.common.PartitionInfo
The partition id
partition() - Method in class org.apache.kafka.common.TopicPartition
 
PARTITION_ASSIGNMENT_STRATEGY_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
partition.assignment.strategy
partitionCountForTopic(String) - Method in class org.apache.kafka.common.Cluster
Get the number of partitions for the given topic
Partitioner - Interface in org.apache.kafka.clients.producer
Partitioner Interface
PARTITIONER_CLASS_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
partitioner.class
PartitionInfo - Class in org.apache.kafka.common
Information about a topic-partition.
PartitionInfo(String, int, Node, Node[], Node[]) - Constructor for class org.apache.kafka.common.PartitionInfo
 
partitions() - Method in class org.apache.kafka.clients.consumer.ConsumerRecords
Get the partitions which have records contained in this record set.
partitions() - Method in exception org.apache.kafka.clients.consumer.InvalidOffsetException
 
partitions() - Method in exception org.apache.kafka.clients.consumer.NoOffsetForPartitionException
 
partitions() - Method in exception org.apache.kafka.clients.consumer.OffsetOutOfRangeException
 
partitionsFor(String) - Method in interface org.apache.kafka.clients.consumer.Consumer
 
partitionsFor(String) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Get metadata about the partitions for a given topic.
partitionsFor(String) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
partitionsFor(String) - Method in class org.apache.kafka.clients.producer.KafkaProducer
Get the partition metadata for the give topic.
partitionsFor(String) - Method in class org.apache.kafka.clients.producer.MockProducer
 
partitionsFor(String) - Method in interface org.apache.kafka.clients.producer.Producer
Get a list of partitions for the given topic for custom partition assignment.
partitionsForNode(int) - Method in class org.apache.kafka.common.Cluster
Get the list of partitions whose leader is this node
partitionsForTopic(String) - Method in class org.apache.kafka.common.Cluster
Get the list of partitions for this topic
pause(TopicPartition...) - Method in interface org.apache.kafka.clients.consumer.Consumer
 
pause(TopicPartition...) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Suspend fetching from the requested partitions.
pause(TopicPartition...) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
paused() - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
poll(long) - Method in interface org.apache.kafka.clients.consumer.Consumer
 
poll(long) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Fetch data for the topics or partitions specified using one of the subscribe/assign APIs.
poll(long) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
port() - Method in class org.apache.kafka.common.Node
The port for this node
position(TopicPartition) - Method in interface org.apache.kafka.clients.consumer.Consumer
 
position(TopicPartition) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Get the offset of the next record that will be fetched (if a record with that offset exists).
position(TopicPartition) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
Producer<K,V> - Interface in org.apache.kafka.clients.producer
The interface for the KafkaProducer
ProducerConfig - Class in org.apache.kafka.clients.producer
Configuration for the Kafka Producer.
ProducerRecord<K,V> - Class in org.apache.kafka.clients.producer
A key/value pair to be sent to Kafka.
ProducerRecord(String, Integer, K, V) - Constructor for class org.apache.kafka.clients.producer.ProducerRecord
Creates a record to be sent to a specified topic and partition
ProducerRecord(String, K, V) - Constructor for class org.apache.kafka.clients.producer.ProducerRecord
Create a record to be sent to Kafka
ProducerRecord(String, V) - Constructor for class org.apache.kafka.clients.producer.ProducerRecord
Create a record with no key

R

RangeAssignor - Class in org.apache.kafka.clients.consumer
The range assignor works on a per-topic basis.
RangeAssignor() - Constructor for class org.apache.kafka.clients.consumer.RangeAssignor
 
rebalance(Collection<TopicPartition>) - Method in class org.apache.kafka.clients.consumer.MockConsumer
Simulate a rebalance event.
RebalanceInProgressException - Exception in org.apache.kafka.common.errors
 
RebalanceInProgressException() - Constructor for exception org.apache.kafka.common.errors.RebalanceInProgressException
 
RebalanceInProgressException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.RebalanceInProgressException
 
RebalanceInProgressException(String) - Constructor for exception org.apache.kafka.common.errors.RebalanceInProgressException
 
RebalanceInProgressException(Throwable) - Constructor for exception org.apache.kafka.common.errors.RebalanceInProgressException
 
RECEIVE_BUFFER_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
receive.buffer.bytes
RECEIVE_BUFFER_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
receive.buffer.bytes
RECONNECT_BACKOFF_MS_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
reconnect.backoff.ms
RECONNECT_BACKOFF_MS_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
reconnect.backoff.ms
RecordBatchTooLargeException - Exception in org.apache.kafka.common.errors
This record batch is larger than the maximum allowable size
RecordBatchTooLargeException() - Constructor for exception org.apache.kafka.common.errors.RecordBatchTooLargeException
 
RecordBatchTooLargeException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.RecordBatchTooLargeException
 
RecordBatchTooLargeException(String) - Constructor for exception org.apache.kafka.common.errors.RecordBatchTooLargeException
 
RecordBatchTooLargeException(Throwable) - Constructor for exception org.apache.kafka.common.errors.RecordBatchTooLargeException
 
RecordMetadata - Class in org.apache.kafka.clients.producer
The metadata for a record that has been acknowledged by the server
RecordMetadata(TopicPartition, long, long) - Constructor for class org.apache.kafka.clients.producer.RecordMetadata
 
records(TopicPartition) - Method in class org.apache.kafka.clients.consumer.ConsumerRecords
Get just the records for the given partition
records(String) - Method in class org.apache.kafka.clients.consumer.ConsumerRecords
Get just the records for the given topic
RecordTooLargeException - Exception in org.apache.kafka.common.errors
This record is larger than the maximum allowable size
RecordTooLargeException() - Constructor for exception org.apache.kafka.common.errors.RecordTooLargeException
 
RecordTooLargeException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.RecordTooLargeException
 
RecordTooLargeException(String) - Constructor for exception org.apache.kafka.common.errors.RecordTooLargeException
 
RecordTooLargeException(Throwable) - Constructor for exception org.apache.kafka.common.errors.RecordTooLargeException
 
RecordTooLargeException(String, Map<TopicPartition, Long>) - Constructor for exception org.apache.kafka.common.errors.RecordTooLargeException
 
recordTooLargePartitions() - Method in exception org.apache.kafka.common.errors.RecordTooLargeException
 
replicas() - Method in class org.apache.kafka.common.PartitionInfo
The complete set of replicas for this partition regardless of whether they are alive or up-to-date
REQUEST_TIMEOUT_MS_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
request.timeout.ms
REQUEST_TIMEOUT_MS_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
request.timeout.ms
resume(TopicPartition...) - Method in interface org.apache.kafka.clients.consumer.Consumer
 
resume(TopicPartition...) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Resume specified partitions which have been paused with KafkaConsumer.pause(TopicPartition...).
resume(TopicPartition...) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
RetriableException - Exception in org.apache.kafka.common.errors
A retryable exception is a transient exception that if retried may succeed.
RetriableException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.RetriableException
 
RetriableException(String) - Constructor for exception org.apache.kafka.common.errors.RetriableException
 
RetriableException(Throwable) - Constructor for exception org.apache.kafka.common.errors.RetriableException
 
RetriableException() - Constructor for exception org.apache.kafka.common.errors.RetriableException
 
RETRIES_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
retries
RETRY_BACKOFF_MS_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
retry.backoff.ms
RETRY_BACKOFF_MS_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
retry.backoff.ms
RoundRobinAssignor - Class in org.apache.kafka.clients.consumer
The roundrobin assignor lays out all the available partitions and all the available consumers.
RoundRobinAssignor() - Constructor for class org.apache.kafka.clients.consumer.RoundRobinAssignor
 

S

scheduleNopPollTask() - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
schedulePollTask(Runnable) - Method in class org.apache.kafka.clients.consumer.MockConsumer
Schedule a task to be executed during a poll().
seek(TopicPartition, long) - Method in interface org.apache.kafka.clients.consumer.Consumer
 
seek(TopicPartition, long) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Overrides the fetch offsets that the consumer will use on the next poll(timeout).
seek(TopicPartition, long) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
seekToBeginning(TopicPartition...) - Method in interface org.apache.kafka.clients.consumer.Consumer
 
seekToBeginning(TopicPartition...) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Seek to the first offset for each of the given partitions.
seekToBeginning(TopicPartition...) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
seekToEnd(TopicPartition...) - Method in interface org.apache.kafka.clients.consumer.Consumer
 
seekToEnd(TopicPartition...) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Seek to the last offset for each of the given partitions.
seekToEnd(TopicPartition...) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
send(ProducerRecord<K, V>) - Method in class org.apache.kafka.clients.producer.KafkaProducer
Asynchronously send a record to a topic.
send(ProducerRecord<K, V>, Callback) - Method in class org.apache.kafka.clients.producer.KafkaProducer
Asynchronously send a record to a topic and invoke the provided callback when the send has been acknowledged.
send(ProducerRecord<K, V>) - Method in class org.apache.kafka.clients.producer.MockProducer
Adds the record to the list of sent records.
send(ProducerRecord<K, V>, Callback) - Method in class org.apache.kafka.clients.producer.MockProducer
Adds the record to the list of sent records.
send(ProducerRecord<K, V>) - Method in interface org.apache.kafka.clients.producer.Producer
Send the given record asynchronously and return a future which will eventually contain the response information.
send(ProducerRecord<K, V>, Callback) - Method in interface org.apache.kafka.clients.producer.Producer
Send a record and invoke the given callback when the record has been acknowledged by the server
SEND_BUFFER_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
send.buffer.bytes
SEND_BUFFER_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
send.buffer.bytes
SerializationException - Exception in org.apache.kafka.common.errors
Any exception during serialization in the producer
SerializationException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.SerializationException
 
SerializationException(String) - Constructor for exception org.apache.kafka.common.errors.SerializationException
 
SerializationException(Throwable) - Constructor for exception org.apache.kafka.common.errors.SerializationException
 
SerializationException() - Constructor for exception org.apache.kafka.common.errors.SerializationException
 
serialize(String, byte[]) - Method in class org.apache.kafka.common.serialization.ByteArraySerializer
 
serialize(String, Integer) - Method in class org.apache.kafka.common.serialization.IntegerSerializer
 
serialize(String, Long) - Method in class org.apache.kafka.common.serialization.LongSerializer
 
serialize(String, T) - Method in interface org.apache.kafka.common.serialization.Serializer
 
serialize(String, String) - Method in class org.apache.kafka.common.serialization.StringSerializer
 
Serializer<T> - Interface in org.apache.kafka.common.serialization
 
SESSION_TIMEOUT_MS_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
session.timeout.ms
setException(KafkaException) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
StringDeserializer - Class in org.apache.kafka.common.serialization
String encoding defaults to UTF8 and can be customized by setting the property key.deserializer.encoding, value.deserializer.encoding or deserializer.encoding.
StringDeserializer() - Constructor for class org.apache.kafka.common.serialization.StringDeserializer
 
StringSerializer - Class in org.apache.kafka.common.serialization
String encoding defaults to UTF8 and can be customized by setting the property key.serializer.encoding, value.serializer.encoding or serializer.encoding.
StringSerializer() - Constructor for class org.apache.kafka.common.serialization.StringSerializer
 
subscribe(List<String>) - Method in interface org.apache.kafka.clients.consumer.Consumer
 
subscribe(List<String>, ConsumerRebalanceListener) - Method in interface org.apache.kafka.clients.consumer.Consumer
 
subscribe(Pattern, ConsumerRebalanceListener) - Method in interface org.apache.kafka.clients.consumer.Consumer
 
subscribe(List<String>, ConsumerRebalanceListener) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Subscribe to the given list of topics to get dynamically assigned partitions.
subscribe(List<String>) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Subscribe to the given list of topics to get dynamically assigned partitions.
subscribe(Pattern, ConsumerRebalanceListener) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Subscribe to all topics matching specified pattern to get dynamically assigned partitions.
subscribe(List<String>) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
subscribe(Pattern, ConsumerRebalanceListener) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
subscribe(List<String>, ConsumerRebalanceListener) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
subscription() - Method in interface org.apache.kafka.clients.consumer.Consumer
 
subscription() - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Get the current subscription.
subscription() - Method in class org.apache.kafka.clients.consumer.MockConsumer
 

T

tags() - Method in class org.apache.kafka.common.MetricName
 
TIMEOUT_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
Deprecated.
This config will be removed in a future release. Please use ProducerConfig.REQUEST_TIMEOUT_MS_CONFIG
TimeoutException - Exception in org.apache.kafka.common.errors
Indicates that a request timed out.
TimeoutException() - Constructor for exception org.apache.kafka.common.errors.TimeoutException
 
TimeoutException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.TimeoutException
 
TimeoutException(String) - Constructor for exception org.apache.kafka.common.errors.TimeoutException
 
TimeoutException(Throwable) - Constructor for exception org.apache.kafka.common.errors.TimeoutException
 
topic() - Method in class org.apache.kafka.clients.consumer.ConsumerRecord
The topic this record is received from
topic() - Method in class org.apache.kafka.clients.producer.ProducerRecord
The topic this record is being sent to
topic() - Method in class org.apache.kafka.clients.producer.RecordMetadata
The topic the record was appended to
topic() - Method in class org.apache.kafka.common.PartitionInfo
The topic name
topic() - Method in class org.apache.kafka.common.TopicPartition
 
TopicAuthorizationException - Exception in org.apache.kafka.common.errors
 
TopicAuthorizationException(Set<String>) - Constructor for exception org.apache.kafka.common.errors.TopicAuthorizationException
 
TopicAuthorizationException(String) - Constructor for exception org.apache.kafka.common.errors.TopicAuthorizationException
 
TopicPartition - Class in org.apache.kafka.common
A topic name and partition number
TopicPartition(String, int) - Constructor for class org.apache.kafka.common.TopicPartition
 
topics() - Method in class org.apache.kafka.common.Cluster
Get all topics.
toString() - Method in class org.apache.kafka.clients.consumer.ConsumerRecord
 
toString() - Method in class org.apache.kafka.clients.consumer.OffsetAndMetadata
 
toString() - Method in class org.apache.kafka.clients.producer.ProducerRecord
 
toString() - Method in class org.apache.kafka.common.Cluster
 
toString() - Method in class org.apache.kafka.common.MetricName
 
toString() - Method in class org.apache.kafka.common.Node
 
toString() - Method in class org.apache.kafka.common.PartitionInfo
 
toString() - Method in class org.apache.kafka.common.TopicPartition
 

U

unauthorizedTopics() - Method in class org.apache.kafka.common.Cluster
 
unauthorizedTopics() - Method in exception org.apache.kafka.common.errors.TopicAuthorizationException
 
UnknownMemberIdException - Exception in org.apache.kafka.common.errors
 
UnknownMemberIdException() - Constructor for exception org.apache.kafka.common.errors.UnknownMemberIdException
 
UnknownMemberIdException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.UnknownMemberIdException
 
UnknownMemberIdException(String) - Constructor for exception org.apache.kafka.common.errors.UnknownMemberIdException
 
UnknownMemberIdException(Throwable) - Constructor for exception org.apache.kafka.common.errors.UnknownMemberIdException
 
UnknownServerException - Exception in org.apache.kafka.common.errors
An error occurred on the server for which the client doesn't have a corresponding error code.
UnknownServerException() - Constructor for exception org.apache.kafka.common.errors.UnknownServerException
 
UnknownServerException(String) - Constructor for exception org.apache.kafka.common.errors.UnknownServerException
 
UnknownServerException(Throwable) - Constructor for exception org.apache.kafka.common.errors.UnknownServerException
 
UnknownServerException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.UnknownServerException
 
UnknownTopicOrPartitionException - Exception in org.apache.kafka.common.errors
This topic/partition doesn't exist
UnknownTopicOrPartitionException() - Constructor for exception org.apache.kafka.common.errors.UnknownTopicOrPartitionException
 
UnknownTopicOrPartitionException(String) - Constructor for exception org.apache.kafka.common.errors.UnknownTopicOrPartitionException
 
UnknownTopicOrPartitionException(Throwable) - Constructor for exception org.apache.kafka.common.errors.UnknownTopicOrPartitionException
 
UnknownTopicOrPartitionException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.UnknownTopicOrPartitionException
 
unsubscribe() - Method in interface org.apache.kafka.clients.consumer.Consumer
 
unsubscribe() - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Unsubscribe from topics currently subscribed with KafkaConsumer.subscribe(List).
unsubscribe() - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
updateBeginningOffsets(Map<TopicPartition, Long>) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
updateEndOffsets(Map<TopicPartition, Long>) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
updatePartitions(String, List<PartitionInfo>) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 

V

value() - Method in class org.apache.kafka.clients.consumer.ConsumerRecord
The value
value() - Method in class org.apache.kafka.clients.producer.ProducerRecord
 
value() - Method in interface org.apache.kafka.common.Metric
The value of the metric
VALUE_DESERIALIZER_CLASS_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
value.deserializer
VALUE_DESERIALIZER_CLASS_DOC - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
 
VALUE_SERIALIZER_CLASS_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
value.serializer
VALUE_SERIALIZER_CLASS_DOC - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
 
valueOf(String) - Static method in enum org.apache.kafka.clients.consumer.OffsetResetStrategy
Returns the enum constant of this type with the specified name.
values() - Static method in enum org.apache.kafka.clients.consumer.OffsetResetStrategy
Returns an array containing the constants of this enum type, in the order they are declared.

W

wakeup() - Method in interface org.apache.kafka.clients.consumer.Consumer
 
wakeup() - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Wakeup the consumer.
wakeup() - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
WakeupException - Exception in org.apache.kafka.common.errors
Exception used to indicate preemption of a blocking operation by an external thread.
WakeupException() - Constructor for exception org.apache.kafka.common.errors.WakeupException
 
A B C D E F G H I K L M N O P R S T U V W