- 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.DefaultStreamsPartitioner
-
This is called when partitioner is closed.
- 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 interface org.apache.kafka.clients.producer.StreamsPartitioner
-
This is called when partitioner is closed.
- 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
-
- 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 class org.apache.kafka.clients.producer.DefaultStreamsPartitioner
-
- 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
- ConsumerRecord(String, int, long, K, V, long, String) - 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
- 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[], int) - Method in class org.apache.kafka.clients.producer.DefaultStreamsPartitioner
-
Compute the partition for the given record.
- 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(String, Object, byte[], Object, byte[], int) - Method in interface org.apache.kafka.clients.producer.StreamsPartitioner
-
Compute the partition for the given record.
- 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() - Method in class org.apache.kafka.clients.consumer.ConsumerRecord
-
The producer for this record.
- Producer<K,V> - Interface in org.apache.kafka.clients.producer
-
- 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
- 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
-
- STREAMS_BUFFER_TIME_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
-
streams.buffer.max.time.ms
- STREAMS_CONSUMER_BUFFER_MEMORY_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
-
streams.consumer.buffer.memory
- STREAMS_CONSUMER_DEFAULT_STREAM_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
-
streams.consumer.default.stream
- STREAMS_HARDMOUNT_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
-
fs.mapr.hardmount
- STREAMS_HARDMOUNT_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
-
fs.mapr.hardmount
- STREAMS_NEGATIVEOFFSET_RECORD_ON_EOF_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
-
- STREAMS_PARALLEL_FLUSHERS_PER_PARTITION_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
-
streams.parallel.flushers.per.partition
- STREAMS_PARTITIONER_CLASS_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
-
streams.partitioner.class
- STREAMS_PRODUCER_DEFAULT_STREAM_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
-
streams.producer.default.stream
- STREAMS_RECORD_STRIP_STREAMPATH_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
-
streams.record.strip.streampath
- STREAMS_RPC_TIMEOUT_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
-
fs.mapr.rpc.timeout
- STREAMS_RPC_TIMEOUT_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
-
fs.mapr.rpc.timeout
- STREAMS_ZEROOFFSET_RECORD_ON_EOF_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
-
- StreamsPartitioner - Interface in org.apache.kafka.clients.producer
-
Partitioner Interface
- 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
-