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

A

ACKS_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
acks
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
 

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
block.on.buffer.full
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.producer.ProducerConfig
bootstrap.servers
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.
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.producer.ProducerConfig
client.id
close() - Method in class org.apache.kafka.clients.producer.KafkaProducer
Close this producer.
close() - Method in class org.apache.kafka.clients.producer.MockProducer
 
close() - Method in interface org.apache.kafka.clients.producer.Producer
Close this producer
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 this deserializer
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
 
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>) - Constructor for class org.apache.kafka.common.Cluster
Create a new cluster with the given nodes and partitions
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 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
 
CorruptRecordException - Exception in org.apache.kafka.common.errors
This exception indicates a record has failed it's 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
 

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.StringDeserializer
 
Deserializer<T> - Interface in org.apache.kafka.common.serialization
 

E

empty() - Static method in class org.apache.kafka.common.Cluster
Create an empty cluster instance with no nodes and no topic-partitions.
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

fillInStackTrace() - Method in exception org.apache.kafka.common.errors.ApiException
 
fillInStackTrace() - Method in exception org.apache.kafka.common.errors.SerializationException
 

G

group() - Method in class org.apache.kafka.common.MetricName
 

H

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

K

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.producer.ProducerRecord
The key (or null if no key is specified)
KEY_SERIALIZER_CLASS_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
key.serializer

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

M

main(String[]) - Static method in class org.apache.kafka.clients.producer.ProducerConfig
 
MAX_IN_FLIGHT_REQUESTS_PER_CONNECTION - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
max.in.flight.requests.per.connection
MAX_REQUEST_SIZE_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
max.request.size
METADATA_FETCH_TIMEOUT_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
metadata.fetch.timeout.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.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 class org.apache.kafka.clients.producer.KafkaProducer
 
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.producer.ProducerConfig
metrics.num.samples
METRICS_SAMPLE_WINDOW_MS_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
metrics.sample.window.ms
MockProducer - 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) - Constructor for class org.apache.kafka.clients.producer.MockProducer
Create a mock producer
MockProducer(boolean) - Constructor for class org.apache.kafka.clients.producer.MockProducer
Create a new mock producer with invented metadata the given autoComplete setting.
MockProducer() - Constructor for class org.apache.kafka.clients.producer.MockProducer
Create a new auto completing mock producer Equivalent to new MockProducer(true)

N

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
 
nodes() - Method in class org.apache.kafka.common.Cluster
 
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() - Constructor for exception org.apache.kafka.common.errors.NotEnoughReplicasAfterAppendException
 
NotEnoughReplicasAfterAppendException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.NotEnoughReplicasAfterAppendException
 
NotEnoughReplicasAfterAppendException(String) - Constructor for exception org.apache.kafka.common.errors.NotEnoughReplicasAfterAppendException
 
NotEnoughReplicasAfterAppendException(Throwable) - 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.producer.RecordMetadata
The offset of the record in the topic/partition.
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.common.errors
This offset is either larger or smaller than the range of offsets the server has for the given partition.
OffsetOutOfRangeException() - Constructor for exception org.apache.kafka.common.errors.OffsetOutOfRangeException
 
OffsetOutOfRangeException(String) - Constructor for exception org.apache.kafka.common.errors.OffsetOutOfRangeException
 
OffsetOutOfRangeException(Throwable) - Constructor for exception org.apache.kafka.common.errors.OffsetOutOfRangeException
 
OffsetOutOfRangeException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.OffsetOutOfRangeException
 
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.
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.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
 
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
 
partitionsFor(String) - Method in class org.apache.kafka.clients.producer.KafkaProducer
 
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
port() - Method in class org.apache.kafka.common.Node
The port for this node
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

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.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
 
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
 
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
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.producer.ProducerConfig
retry.backoff.ms

S

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<byte[], byte[]>) - Method in class org.apache.kafka.clients.producer.MockProducer
Adds the record to the list of sent records.
send(ProducerRecord<byte[], byte[]>, 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.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, 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
 
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
 

T

tags() - Method in class org.apache.kafka.common.MetricName
 
TIMEOUT_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
timeout.ms
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.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
 
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.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

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
 

V

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_SERIALIZER_CLASS_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
value.serializer

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