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

A

AdminUtils - Interface in io.vertx.kafka.admin
Provides a wrapper around important methods in Kafka's AdminUtils, namely
assign(TopicPartition) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
Manually assign a partition to this consumer.
assign(Set<TopicPartition>) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
Manually assign a list of partition to this consumer.
assign(TopicPartition, Handler<AsyncResult<Void>>) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
Manually assign a partition to this consumer.
assign(Set<TopicPartition>, Handler<AsyncResult<Void>>) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
Manually assign a list of partition to this consumer.
assign(Set<TopicPartition>) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
Manually assign a set of partitions to this consumer.
assign(Set<TopicPartition>, Handler<AsyncResult<Void>>) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
Manually assign a set of partitions to this consumer.
assignment(Handler<AsyncResult<Set<TopicPartition>>>) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
Get the set of partitions currently assigned to this consumer.
assignment(Handler<AsyncResult<Set<TopicPartition>>>) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
Get the set of partitions currently assigned to this consumer.
asStream() - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
 
asStream() - Method in interface io.vertx.kafka.client.producer.KafkaProducer
 

B

batchHandler(Handler<KafkaConsumerRecords<K, V>>) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
Set the handler to be used when batches of messages are fetched from the Kafka server.
batchHandler(Handler<ConsumerRecords<K, V>>) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
Set the handler that will be called when a new batch of records is returned from Kafka.
beginningOffsets(Set<TopicPartition>, Handler<AsyncResult<Map<TopicPartition, Long>>>) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
Get the first offset for the given partitions.
beginningOffsets(TopicPartition, Handler<AsyncResult<Long>>) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
Get the first offset for the given partitions.
beginningOffsets(Set<TopicPartition>, Handler<AsyncResult<Map<TopicPartition, Long>>>) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
Get the first offset for the given partitions.
beginningOffsets(TopicPartition, Handler<AsyncResult<Long>>) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
Get the first offset for the given partition.
Buffer() - Static method in class io.vertx.kafka.client.serialization.VertxSerdes
 
BufferDeserializer - Class in io.vertx.kafka.client.serialization
Kafka deserializer for raw bytes in a buffer
BufferDeserializer() - Constructor for class io.vertx.kafka.client.serialization.BufferDeserializer
 
BufferSerde() - Constructor for class io.vertx.kafka.client.serialization.VertxSerdes.BufferSerde
 
BufferSerializer - Class in io.vertx.kafka.client.serialization
Kafka serializer for raw bytes in a buffer
BufferSerializer() - Constructor for class io.vertx.kafka.client.serialization.BufferSerializer
 

C

changeTopicConfig(String, Map<String, String>, Handler<AsyncResult<Void>>) - Method in interface io.vertx.kafka.admin.AdminUtils
Updates the configuration of the topic given by topicName.
checksum() - Method in interface io.vertx.kafka.client.consumer.KafkaConsumerRecord
 
checksum() - Method in class io.vertx.kafka.client.producer.RecordMetadata
 
close(Handler<AsyncResult<Void>>) - Method in interface io.vertx.kafka.admin.AdminUtils
Closes the underlying connection to Zookeeper.
close() - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
Close the consumer
close(Handler<AsyncResult<Void>>) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
Close the consumer
close() - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
Close the stream
close(Handler<AsyncResult<Void>>) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
Close the stream
close() - Method in interface io.vertx.kafka.client.producer.KafkaProducer
Close the producer
close(Handler<AsyncResult<Void>>) - Method in interface io.vertx.kafka.client.producer.KafkaProducer
Close the producer
close(long, Handler<AsyncResult<Void>>) - Method in interface io.vertx.kafka.client.producer.KafkaProducer
Close the producer
close() - Method in interface io.vertx.kafka.client.producer.KafkaWriteStream
Close the stream
close(Handler<AsyncResult<Void>>) - Method in interface io.vertx.kafka.client.producer.KafkaWriteStream
Close the stream
close(long, Handler<AsyncResult<Void>>) - Method in interface io.vertx.kafka.client.producer.KafkaWriteStream
Close the stream
close() - Method in class io.vertx.kafka.client.serialization.BufferDeserializer
 
close() - Method in class io.vertx.kafka.client.serialization.BufferSerializer
 
close() - Method in class io.vertx.kafka.client.serialization.JsonArrayDeserializer
 
close() - Method in class io.vertx.kafka.client.serialization.JsonArraySerializer
 
close() - Method in class io.vertx.kafka.client.serialization.JsonObjectDeserializer
 
close() - Method in class io.vertx.kafka.client.serialization.JsonObjectSerializer
 
commit() - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
Commit current offsets for all the subscribed list of topics and partition.
commit(Handler<AsyncResult<Void>>) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
Commit current offsets for all the subscribed list of topics and partition.
commit(Map<TopicPartition, OffsetAndMetadata>) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
Commit the specified offsets for the specified list of topics and partitions to Kafka.
commit(Map<TopicPartition, OffsetAndMetadata>, Handler<AsyncResult<Map<TopicPartition, OffsetAndMetadata>>>) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
Commit the specified offsets for the specified list of topics and partitions to Kafka.
commit() - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
Commit current offsets for all the subscribed list of topics and partition.
commit(Handler<AsyncResult<Map<TopicPartition, OffsetAndMetadata>>>) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
Commit current offsets for all the subscribed list of topics and partition.
commit(Map<TopicPartition, OffsetAndMetadata>) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
Commit the specified offsets for the specified list of topics and partitions to Kafka.
commit(Map<TopicPartition, OffsetAndMetadata>, Handler<AsyncResult<Map<TopicPartition, OffsetAndMetadata>>>) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
Commit the specified offsets for the specified list of topics and partitions to Kafka.
committed(TopicPartition, Handler<AsyncResult<OffsetAndMetadata>>) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
Get the last committed offset for the given partition (whether the commit happened by this process or another).
committed(TopicPartition, Handler<AsyncResult<OffsetAndMetadata>>) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
Get the last committed offset for the given partition (whether the commit happened by this process or another).
configure(Map<String, ?>, boolean) - Method in class io.vertx.kafka.client.serialization.BufferDeserializer
 
configure(Map<String, ?>, boolean) - Method in class io.vertx.kafka.client.serialization.BufferSerializer
 
configure(Map<String, ?>, boolean) - Method in class io.vertx.kafka.client.serialization.JsonArrayDeserializer
 
configure(Map<String, ?>, boolean) - Method in class io.vertx.kafka.client.serialization.JsonArraySerializer
 
configure(Map<String, ?>, boolean) - Method in class io.vertx.kafka.client.serialization.JsonObjectDeserializer
 
configure(Map<String, ?>, boolean) - Method in class io.vertx.kafka.client.serialization.JsonObjectSerializer
 
create(Vertx, String) - Static method in interface io.vertx.kafka.admin.AdminUtils
Create a new AdminUtils instance
create(Vertx, String, boolean) - Static method in interface io.vertx.kafka.admin.AdminUtils
Create a new AdminUtils instance
create(Vertx, String, int, boolean, boolean) - Static method in interface io.vertx.kafka.admin.AdminUtils
Create a new AdminUtils instance
create(Vertx, Consumer<K, V>) - Static method in interface io.vertx.kafka.client.consumer.KafkaConsumer
Create a new KafkaConsumer instance from a native Consumer.
create(Vertx, Map<String, String>) - Static method in interface io.vertx.kafka.client.consumer.KafkaConsumer
Create a new KafkaConsumer instance
create(Vertx, Map<String, String>, Class<K>, Class<V>) - Static method in interface io.vertx.kafka.client.consumer.KafkaConsumer
Create a new KafkaConsumer instance
create(Vertx, Properties) - Static method in interface io.vertx.kafka.client.consumer.KafkaConsumer
Create a new KafkaConsumer instance
create(Vertx, Properties, Class<K>, Class<V>) - Static method in interface io.vertx.kafka.client.consumer.KafkaConsumer
Create a new KafkaConsumer instance
create(Vertx, Properties) - Static method in interface io.vertx.kafka.client.consumer.KafkaReadStream
Create a new KafkaReadStream instance
create(Vertx, Properties, Class<K>, Class<V>) - Static method in interface io.vertx.kafka.client.consumer.KafkaReadStream
Create a new KafkaReadStream instance
create(Vertx, Map<String, Object>) - Static method in interface io.vertx.kafka.client.consumer.KafkaReadStream
Create a new KafkaReadStream instance
create(Vertx, Map<String, Object>, Class<K>, Class<V>) - Static method in interface io.vertx.kafka.client.consumer.KafkaReadStream
Create a new KafkaReadStream instance
create(Vertx, Consumer<K, V>) - Static method in interface io.vertx.kafka.client.consumer.KafkaReadStream
Create a new KafkaReadStream instance
create(Vertx, Producer<K, V>) - Static method in interface io.vertx.kafka.client.producer.KafkaProducer
Create a new KafkaProducer instance from a native Producer.
create(Vertx, Map<String, String>) - Static method in interface io.vertx.kafka.client.producer.KafkaProducer
Create a new KafkaProducer instance
create(Vertx, Map<String, String>, Class<K>, Class<V>) - Static method in interface io.vertx.kafka.client.producer.KafkaProducer
Create a new KafkaProducer instance
create(Vertx, Properties) - Static method in interface io.vertx.kafka.client.producer.KafkaProducer
Create a new KafkaProducer instance
create(Vertx, Properties, Class<K>, Class<V>) - Static method in interface io.vertx.kafka.client.producer.KafkaProducer
Create a new KafkaProducer instance
create(String, K, V, Long, Integer) - Static method in interface io.vertx.kafka.client.producer.KafkaProducerRecord
Create a concrete instance of a Vert.x producer record
create(String, K, V, Integer) - Static method in interface io.vertx.kafka.client.producer.KafkaProducerRecord
Create a concrete instance of a Vert.x producer record
create(String, K, V) - Static method in interface io.vertx.kafka.client.producer.KafkaProducerRecord
Create a concrete instance of a Vert.x producer record
create(String, V) - Static method in interface io.vertx.kafka.client.producer.KafkaProducerRecord
Create a concrete instance of a Vert.x producer record
create(Vertx, Properties) - Static method in interface io.vertx.kafka.client.producer.KafkaWriteStream
Create a new KafkaWriteStream instance
create(Vertx, Properties, Class<K>, Class<V>) - Static method in interface io.vertx.kafka.client.producer.KafkaWriteStream
Create a new KafkaWriteStream instance
create(Vertx, Map<String, Object>) - Static method in interface io.vertx.kafka.client.producer.KafkaWriteStream
Create a new KafkaWriteStream instance
create(Vertx, Map<String, Object>, Class<K>, Class<V>) - Static method in interface io.vertx.kafka.client.producer.KafkaWriteStream
Create a new KafkaWriteStream instance
create(Vertx, Producer<K, V>) - Static method in interface io.vertx.kafka.client.producer.KafkaWriteStream
Create a new KafkaWriteStream instance
createShared(Vertx, String, Properties) - Static method in interface io.vertx.kafka.client.producer.KafkaProducer
Get or create a KafkaProducer instance which shares its stream with any other KafkaProducer created with the same name
createShared(Vertx, String, Map<String, String>) - Static method in interface io.vertx.kafka.client.producer.KafkaProducer
Get or create a KafkaProducer instance which shares its stream with any other KafkaProducer created with the same name
createShared(Vertx, String, Map<String, String>, Class<K>, Class<V>) - Static method in interface io.vertx.kafka.client.producer.KafkaProducer
Get or create a KafkaProducer instance which shares its stream with any other KafkaProducer created with the same name
createShared(Vertx, String, Properties, Class<K>, Class<V>) - Static method in interface io.vertx.kafka.client.producer.KafkaProducer
Get or create a KafkaProducer instance which shares its stream with any other KafkaProducer created with the same name
createTopic(String, int, int, Handler<AsyncResult<Void>>) - Method in interface io.vertx.kafka.admin.AdminUtils
Creates a new Kafka topic on all Brokers managed by the given Zookeeper instance(s)
createTopic(String, int, int, Map<String, String>, Handler<AsyncResult<Void>>) - Method in interface io.vertx.kafka.admin.AdminUtils
Creates a new Kafka topic on all Brokers managed by the given Zookeeper instance(s).

D

DEFAULT_MAX_SIZE - Static variable in interface io.vertx.kafka.client.producer.KafkaWriteStream
 
deleteTopic(String, Handler<AsyncResult<Void>>) - Method in interface io.vertx.kafka.admin.AdminUtils
Delete the Kafka topic given by the topicName.
deserialize(String, byte[]) - Method in class io.vertx.kafka.client.serialization.BufferDeserializer
 
deserialize(String, byte[]) - Method in class io.vertx.kafka.client.serialization.JsonArrayDeserializer
 
deserialize(String, byte[]) - Method in class io.vertx.kafka.client.serialization.JsonObjectDeserializer
 
drainHandler(Handler<Void>) - Method in interface io.vertx.kafka.client.producer.KafkaProducer
 

E

end() - Method in interface io.vertx.kafka.client.producer.KafkaProducer
 
end(KafkaProducerRecord<K, V>) - Method in interface io.vertx.kafka.client.producer.KafkaProducer
 
endHandler(Handler<Void>) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
 
endOffsets(Set<TopicPartition>, Handler<AsyncResult<Map<TopicPartition, Long>>>) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
Get the last offset for the given partitions.
endOffsets(TopicPartition, Handler<AsyncResult<Long>>) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
Get the last offset for the given partition.
endOffsets(Set<TopicPartition>, Handler<AsyncResult<Map<TopicPartition, Long>>>) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
Get the last offset for the given partitions.
endOffsets(TopicPartition, Handler<AsyncResult<Long>>) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
Get the last offset for the given partition.
exceptionHandler(Handler<Throwable>) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
 
exceptionHandler(Handler<Throwable>) - Method in interface io.vertx.kafka.client.producer.KafkaProducer
 

F

flush(Handler<Void>) - Method in interface io.vertx.kafka.client.producer.KafkaProducer
Invoking this method makes all buffered records immediately available to write
flush(Handler<Void>) - Method in interface io.vertx.kafka.client.producer.KafkaWriteStream
Invoking this method makes all buffered records immediately available to write
fromJson(JsonObject, PartitionInfo) - Static method in class io.vertx.kafka.client.common.PartitionInfoConverter
 

G

getHost() - Method in class io.vertx.kafka.client.common.Node
 
getId() - Method in class io.vertx.kafka.client.common.Node
 
getIdString() - Method in class io.vertx.kafka.client.common.Node
 
getInSyncReplicas() - Method in class io.vertx.kafka.client.common.PartitionInfo
 
getLeader() - Method in class io.vertx.kafka.client.common.PartitionInfo
 
getMetadata() - Method in class io.vertx.kafka.client.consumer.OffsetAndMetadata
 
getOffset() - Method in class io.vertx.kafka.client.consumer.OffsetAndMetadata
 
getOffset() - Method in class io.vertx.kafka.client.consumer.OffsetAndTimestamp
 
getOffset() - Method in class io.vertx.kafka.client.producer.RecordMetadata
 
getPartition() - Method in class io.vertx.kafka.client.common.PartitionInfo
 
getPartition() - Method in class io.vertx.kafka.client.common.TopicPartition
 
getPartition() - Method in class io.vertx.kafka.client.producer.RecordMetadata
 
getPort() - Method in class io.vertx.kafka.client.common.Node
 
getReplicas() - Method in class io.vertx.kafka.client.common.PartitionInfo
 
getTimestamp() - Method in class io.vertx.kafka.client.consumer.OffsetAndTimestamp
 
getTimestamp() - Method in class io.vertx.kafka.client.producer.RecordMetadata
 
getTopic() - Method in class io.vertx.kafka.client.common.PartitionInfo
 
getTopic() - Method in class io.vertx.kafka.client.common.TopicPartition
 
getTopic() - Method in class io.vertx.kafka.client.producer.RecordMetadata
 

H

handler(Handler<KafkaConsumerRecord<K, V>>) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
 
hasRack() - Method in class io.vertx.kafka.client.common.Node
 

I

io.vertx.kafka.admin - package io.vertx.kafka.admin
= Vert.x Kafka AdminUtils :toc: left :lang: $lang :$lang: $lang This component provides a vert.x wrapper around the most important functions of Kafka's AdminUtils.
io.vertx.kafka.client.common - package io.vertx.kafka.client.common
 
io.vertx.kafka.client.consumer - package io.vertx.kafka.client.consumer
 
io.vertx.kafka.client.producer - package io.vertx.kafka.client.producer
 
io.vertx.kafka.client.serialization - package io.vertx.kafka.client.serialization
 
isEmpty() - Method in class io.vertx.kafka.client.common.Node
 
isEmpty() - Method in interface io.vertx.kafka.client.consumer.KafkaConsumerRecords
 

J

JsonArray() - Static method in class io.vertx.kafka.client.serialization.VertxSerdes
 
JsonArrayDeserializer - Class in io.vertx.kafka.client.serialization
Kafka deserializer for raw bytes in a buffer
JsonArrayDeserializer() - Constructor for class io.vertx.kafka.client.serialization.JsonArrayDeserializer
 
JsonArraySerde() - Constructor for class io.vertx.kafka.client.serialization.VertxSerdes.JsonArraySerde
 
JsonArraySerializer - Class in io.vertx.kafka.client.serialization
Kafka serializer for raw bytes in a buffer
JsonArraySerializer() - Constructor for class io.vertx.kafka.client.serialization.JsonArraySerializer
 
JsonObject() - Static method in class io.vertx.kafka.client.serialization.VertxSerdes
 
JsonObjectDeserializer - Class in io.vertx.kafka.client.serialization
Kafka deserializer for raw bytes in a buffer
JsonObjectDeserializer() - Constructor for class io.vertx.kafka.client.serialization.JsonObjectDeserializer
 
JsonObjectSerde() - Constructor for class io.vertx.kafka.client.serialization.VertxSerdes.JsonObjectSerde
 
JsonObjectSerializer - Class in io.vertx.kafka.client.serialization
Kafka serializer for raw bytes in a buffer
JsonObjectSerializer() - Constructor for class io.vertx.kafka.client.serialization.JsonObjectSerializer
 

K

KafkaConsumer<K,V> - Interface in io.vertx.kafka.client.consumer
Vert.x Kafka consumer.
KafkaConsumerRecord<K,V> - Interface in io.vertx.kafka.client.consumer
Vert.x Kafka consumer record
KafkaConsumerRecords<K,V> - Interface in io.vertx.kafka.client.consumer
Vert.x Kafka consumer records
KafkaProducer<K,V> - Interface in io.vertx.kafka.client.producer
Vert.x Kafka producer.
KafkaProducerRecord<K,V> - Interface in io.vertx.kafka.client.producer
Vert.x Kafka producer record.
KafkaReadStream<K,V> - Interface in io.vertx.kafka.client.consumer
A ReadStream for consuming Kafka ConsumerRecord.
KafkaWriteStream<K,V> - Interface in io.vertx.kafka.client.producer
A WriteStream for writing to Kafka ProducerRecord.
key() - Method in interface io.vertx.kafka.client.consumer.KafkaConsumerRecord
 
key() - Method in interface io.vertx.kafka.client.producer.KafkaProducerRecord
 

L

listTopics(Handler<AsyncResult<Map<String, List<PartitionInfo>>>>) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
Get metadata about partitions for all topics that the user is authorized to view.
listTopics(Handler<AsyncResult<Map<String, List<PartitionInfo>>>>) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
Get metadata about partitions for all topics that the user is authorized to view.

N

Node - Class in io.vertx.kafka.client.common
Information about a Kafka cluster node
Node() - Constructor for class io.vertx.kafka.client.common.Node
Constructor
Node(boolean, String, int, String, boolean, int, String) - Constructor for class io.vertx.kafka.client.common.Node
Constructor
Node(JsonObject) - Constructor for class io.vertx.kafka.client.common.Node
Constructor (from JSON representation)

O

offset() - Method in interface io.vertx.kafka.client.consumer.KafkaConsumerRecord
 
OffsetAndMetadata - Class in io.vertx.kafka.client.consumer
Provide additional metadata when an offset is committed
OffsetAndMetadata() - Constructor for class io.vertx.kafka.client.consumer.OffsetAndMetadata
Constructor
OffsetAndMetadata(long, String) - Constructor for class io.vertx.kafka.client.consumer.OffsetAndMetadata
Constructor
OffsetAndMetadata(JsonObject) - Constructor for class io.vertx.kafka.client.consumer.OffsetAndMetadata
Constructor (from JSON representation)
OffsetAndMetadata(OffsetAndMetadata) - Constructor for class io.vertx.kafka.client.consumer.OffsetAndMetadata
Constructor (copy)
OffsetAndTimestamp - Class in io.vertx.kafka.client.consumer
Represent information related to a Offset with timestamp information
OffsetAndTimestamp() - Constructor for class io.vertx.kafka.client.consumer.OffsetAndTimestamp
Constructor
OffsetAndTimestamp(long, long) - Constructor for class io.vertx.kafka.client.consumer.OffsetAndTimestamp
Constructor
OffsetAndTimestamp(JsonObject) - Constructor for class io.vertx.kafka.client.consumer.OffsetAndTimestamp
Constructor (from JSON representation)
OffsetAndTimestamp(OffsetAndTimestamp) - Constructor for class io.vertx.kafka.client.consumer.OffsetAndTimestamp
Constructor (copy)
offsetsForTimes(Map<TopicPartition, Long>, Handler<AsyncResult<Map<TopicPartition, OffsetAndTimestamp>>>) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
Look up the offsets for the given partitions by timestamp.
offsetsForTimes(TopicPartition, Long, Handler<AsyncResult<OffsetAndTimestamp>>) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
Look up the offset for the given partition by timestamp.
offsetsForTimes(Map<TopicPartition, Long>, Handler<AsyncResult<Map<TopicPartition, OffsetAndTimestamp>>>) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
Look up the offsets for the given partitions by timestamp.
offsetsForTimes(TopicPartition, long, Handler<AsyncResult<OffsetAndTimestamp>>) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
* Look up the offset for the given partition by timestamp.

P

partition() - Method in interface io.vertx.kafka.client.consumer.KafkaConsumerRecord
 
partition() - Method in interface io.vertx.kafka.client.producer.KafkaProducerRecord
 
PartitionInfo - Class in io.vertx.kafka.client.common
Information about a specific Kafka topic partition
PartitionInfo() - Constructor for class io.vertx.kafka.client.common.PartitionInfo
Constructor
PartitionInfo(List<Node>, Node, int, List<Node>, String) - Constructor for class io.vertx.kafka.client.common.PartitionInfo
Constructor
PartitionInfo(JsonObject) - Constructor for class io.vertx.kafka.client.common.PartitionInfo
Constructor (from JSON representation)
PartitionInfoConverter - Class in io.vertx.kafka.client.common
Converter for PartitionInfo.
PartitionInfoConverter() - Constructor for class io.vertx.kafka.client.common.PartitionInfoConverter
 
partitionsAssignedHandler(Handler<Set<TopicPartition>>) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
Set the handler called when topic partitions are assigned to the consumer
partitionsAssignedHandler(Handler<Set<TopicPartition>>) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
Set the handler called when topic partitions are assigned to the consumer
partitionsFor(String, Handler<AsyncResult<List<PartitionInfo>>>) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
Get metadata about the partitions for a given topic.
partitionsFor(String, Handler<AsyncResult<List<PartitionInfo>>>) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
Get metadata about the partitions for a given topic.
partitionsFor(String, Handler<AsyncResult<List<PartitionInfo>>>) - Method in interface io.vertx.kafka.client.producer.KafkaProducer
Get the partition metadata for the give topic.
partitionsFor(String, Handler<AsyncResult<List<PartitionInfo>>>) - Method in interface io.vertx.kafka.client.producer.KafkaWriteStream
Get the partition metadata for the give topic.
partitionsRevokedHandler(Handler<Set<TopicPartition>>) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
Set the handler called when topic partitions are revoked to the consumer
partitionsRevokedHandler(Handler<Set<TopicPartition>>) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
Set the handler called when topic partitions are revoked to the consumer
pause() - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
 
pause(TopicPartition) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
Suspend fetching from the requested partition.
pause(Set<TopicPartition>) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
Suspend fetching from the requested partitions.
pause(TopicPartition, Handler<AsyncResult<Void>>) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
Suspend fetching from the requested partition.
pause(Set<TopicPartition>, Handler<AsyncResult<Void>>) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
Suspend fetching from the requested partitions.
pause(Set<TopicPartition>) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
Suspend fetching from the requested partitions.
pause(Set<TopicPartition>, Handler<AsyncResult<Void>>) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
Suspend fetching from the requested partitions.
paused(Handler<AsyncResult<Set<TopicPartition>>>) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
Get the set of partitions that were previously paused by a call to pause(Set).
paused(Handler<AsyncResult<Set<TopicPartition>>>) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
Get the set of partitions that were previously paused by a call to KafkaReadStream.pause(Set).
pollTimeout(long) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
Sets the poll timeout (in ms) for the underlying native Kafka Consumer.
pollTimeout(long) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
Sets the poll timeout (in ms) for the underlying native Kafka Consumer.
position(TopicPartition, Handler<AsyncResult<Long>>) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
Get the offset of the next record that will be fetched (if a record with that offset exists).
position(TopicPartition, Handler<AsyncResult<Long>>) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
Get the offset of the next record that will be fetched (if a record with that offset exists).

R

rack() - Method in class io.vertx.kafka.client.common.Node
 
record() - Method in interface io.vertx.kafka.client.consumer.KafkaConsumerRecord
 
record() - Method in interface io.vertx.kafka.client.producer.KafkaProducerRecord
 
recordAt(int) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumerRecords
Get the record at the given index
RecordMetadata - Class in io.vertx.kafka.client.producer
Metadata related to a Kafka record
RecordMetadata() - Constructor for class io.vertx.kafka.client.producer.RecordMetadata
Constructor
RecordMetadata(long, long, int, long, String) - Constructor for class io.vertx.kafka.client.producer.RecordMetadata
Constructor
RecordMetadata(JsonObject) - Constructor for class io.vertx.kafka.client.producer.RecordMetadata
Constructor (from JSON representation)
records() - Method in interface io.vertx.kafka.client.consumer.KafkaConsumerRecords
 
resume() - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
 
resume(TopicPartition) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
Resume specified partition which have been paused with pause.
resume(Set<TopicPartition>) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
Resume specified partitions which have been paused with pause.
resume(TopicPartition, Handler<AsyncResult<Void>>) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
Resume specified partition which have been paused with pause.
resume(Set<TopicPartition>, Handler<AsyncResult<Void>>) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
Resume specified partitions which have been paused with pause.
resume(Set<TopicPartition>) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
Resume specified partitions which have been paused with pause.
resume(Set<TopicPartition>, Handler<AsyncResult<Void>>) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
Resume specified partitions which have been paused with pause.

S

seek(TopicPartition, long) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
Overrides the fetch offsets that the consumer will use on the next poll.
seek(TopicPartition, long, Handler<AsyncResult<Void>>) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
Overrides the fetch offsets that the consumer will use on the next poll.
seek(TopicPartition, long) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
Overrides the fetch offsets that the consumer will use on the next poll.
seek(TopicPartition, long, Handler<AsyncResult<Void>>) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
Overrides the fetch offsets that the consumer will use on the next poll.
seekToBeginning(TopicPartition) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
Seek to the first offset for each of the given partition.
seekToBeginning(Set<TopicPartition>) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
Seek to the first offset for each of the given partitions.
seekToBeginning(TopicPartition, Handler<AsyncResult<Void>>) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
Seek to the first offset for each of the given partition.
seekToBeginning(Set<TopicPartition>, Handler<AsyncResult<Void>>) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
Seek to the first offset for each of the given partitions.
seekToBeginning(Set<TopicPartition>) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
Seek to the first offset for each of the given partitions.
seekToBeginning(Set<TopicPartition>, Handler<AsyncResult<Void>>) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
Seek to the first offset for each of the given partitions.
seekToEnd(TopicPartition) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
Seek to the last offset for each of the given partition.
seekToEnd(Set<TopicPartition>) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
Seek to the last offset for each of the given partitions.
seekToEnd(TopicPartition, Handler<AsyncResult<Void>>) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
Seek to the last offset for each of the given partition.
seekToEnd(Set<TopicPartition>, Handler<AsyncResult<Void>>) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
Seek to the last offset for each of the given partitions.
seekToEnd(Set<TopicPartition>) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
Seek to the last offset for each of the given partitions.
seekToEnd(Set<TopicPartition>, Handler<AsyncResult<Void>>) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
Seek to the last offset for each of the given partitions.
serdeFrom(Class<T>) - Static method in class io.vertx.kafka.client.serialization.VertxSerdes
 
serialize(String, Buffer) - Method in class io.vertx.kafka.client.serialization.BufferSerializer
 
serialize(String, JsonArray) - Method in class io.vertx.kafka.client.serialization.JsonArraySerializer
 
serialize(String, JsonObject) - Method in class io.vertx.kafka.client.serialization.JsonObjectSerializer
 
setChecksum(long) - Method in class io.vertx.kafka.client.producer.RecordMetadata
Set the checksum (CRC32) of the record.
setHasRack(boolean) - Method in class io.vertx.kafka.client.common.Node
Set if this node has a defined rack
setHost(String) - Method in class io.vertx.kafka.client.common.Node
Set the host name for this node
setId(int) - Method in class io.vertx.kafka.client.common.Node
Set the node id of this node
setIdString(String) - Method in class io.vertx.kafka.client.common.Node
Set the string representation of the node id
setInSyncReplicas(List<Node>) - Method in class io.vertx.kafka.client.common.PartitionInfo
Set the subset of the replicas that are in sync
setIsEmpty(boolean) - Method in class io.vertx.kafka.client.common.Node
Set if this node is empty
setLeader(Node) - Method in class io.vertx.kafka.client.common.PartitionInfo
Set the node id of the node currently acting as a leader
setMetadata(String) - Method in class io.vertx.kafka.client.consumer.OffsetAndMetadata
Set additional metadata for the offset committed
setOffset(long) - Method in class io.vertx.kafka.client.consumer.OffsetAndMetadata
Set the offset to commit
setOffset(long) - Method in class io.vertx.kafka.client.consumer.OffsetAndTimestamp
Set the offset
setOffset(long) - Method in class io.vertx.kafka.client.producer.RecordMetadata
Set the offset of the record in the topic/partition.
setPartition(int) - Method in class io.vertx.kafka.client.common.PartitionInfo
Set the partition id
setPartition(int) - Method in class io.vertx.kafka.client.common.TopicPartition
Set the partition number
setPartition(int) - Method in class io.vertx.kafka.client.producer.RecordMetadata
Set the partition the record was sent to
setPort(int) - Method in class io.vertx.kafka.client.common.Node
Set the port for this node
setRack(String) - Method in class io.vertx.kafka.client.common.Node
Set the rack for this node
setReplicas(List<Node>) - Method in class io.vertx.kafka.client.common.PartitionInfo
Set the complete set of replicas for this partition
setTimestamp(long) - Method in class io.vertx.kafka.client.consumer.OffsetAndTimestamp
Set the timestamp
setTimestamp(long) - Method in class io.vertx.kafka.client.producer.RecordMetadata
Set the timestamp of the record in the topic/partition
setTopic(String) - Method in class io.vertx.kafka.client.common.PartitionInfo
Set the topic name
setTopic(String) - Method in class io.vertx.kafka.client.common.TopicPartition
Set the topic name
setTopic(String) - Method in class io.vertx.kafka.client.producer.RecordMetadata
Set the topic the record was appended to
setWriteQueueMaxSize(int) - Method in interface io.vertx.kafka.client.producer.KafkaProducer
 
size() - Method in interface io.vertx.kafka.client.consumer.KafkaConsumerRecords
 
subscribe(String) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
Subscribe to the given topic to get dynamically assigned partitions.
subscribe(Set<String>) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
Subscribe to the given list of topics to get dynamically assigned partitions.
subscribe(String, Handler<AsyncResult<Void>>) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
Subscribe to the given topic to get dynamically assigned partitions.
subscribe(Set<String>, Handler<AsyncResult<Void>>) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
Subscribe to the given list of topics to get dynamically assigned partitions.
subscribe(Set<String>) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
Subscribe to the given list of topics to get dynamically assigned partitions.
subscribe(Set<String>, Handler<AsyncResult<Void>>) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
Subscribe to the given list of topics to get dynamically assigned partitions.
subscription(Handler<AsyncResult<Set<String>>>) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
Get the current subscription.
subscription(Handler<AsyncResult<Set<String>>>) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
Get the current subscription.

T

timestamp() - Method in interface io.vertx.kafka.client.consumer.KafkaConsumerRecord
 
timestamp() - Method in interface io.vertx.kafka.client.producer.KafkaProducerRecord
 
timestampType() - Method in interface io.vertx.kafka.client.consumer.KafkaConsumerRecord
 
toJson() - Method in class io.vertx.kafka.client.common.Node
Convert object to JSON representation
toJson() - Method in class io.vertx.kafka.client.common.PartitionInfo
Convert object to JSON representation
toJson(PartitionInfo, JsonObject) - Static method in class io.vertx.kafka.client.common.PartitionInfoConverter
 
toJson() - Method in class io.vertx.kafka.client.common.TopicPartition
Convert object to JSON representation
toJson() - Method in class io.vertx.kafka.client.consumer.OffsetAndMetadata
Convert object to JSON representation
toJson() - Method in class io.vertx.kafka.client.consumer.OffsetAndTimestamp
Convert object to JSON representation
toJson() - Method in class io.vertx.kafka.client.producer.RecordMetadata
Convert object to JSON representation
topic() - Method in interface io.vertx.kafka.client.consumer.KafkaConsumerRecord
 
topic() - Method in interface io.vertx.kafka.client.producer.KafkaProducerRecord
 
topicExists(String, Handler<AsyncResult<Boolean>>) - Method in interface io.vertx.kafka.admin.AdminUtils
Checks if the Kafka topic given by topicName does exist.
TopicPartition - Class in io.vertx.kafka.client.common
Represent information related to a partition for a topic
TopicPartition() - Constructor for class io.vertx.kafka.client.common.TopicPartition
Constructor
TopicPartition(String, int) - Constructor for class io.vertx.kafka.client.common.TopicPartition
Constructor
TopicPartition(JsonObject) - Constructor for class io.vertx.kafka.client.common.TopicPartition
Constructor (from JSON representation)
TopicPartition(TopicPartition) - Constructor for class io.vertx.kafka.client.common.TopicPartition
Constructor (copy)
toString() - Method in class io.vertx.kafka.client.common.Node
 
toString() - Method in class io.vertx.kafka.client.common.PartitionInfo
 
toString() - Method in class io.vertx.kafka.client.common.TopicPartition
 
toString() - Method in class io.vertx.kafka.client.consumer.OffsetAndMetadata
 
toString() - Method in class io.vertx.kafka.client.consumer.OffsetAndTimestamp
 

U

unsubscribe() - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
Unsubscribe from topics currently subscribed with subscribe.
unsubscribe(Handler<AsyncResult<Void>>) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
Unsubscribe from topics currently subscribed with subscribe.
unsubscribe() - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
Unsubscribe from topics currently subscribed with subscribe.
unsubscribe(Handler<AsyncResult<Void>>) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
Unsubscribe from topics currently subscribed with subscribe.
unwrap() - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
 
unwrap() - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
 
unwrap() - Method in interface io.vertx.kafka.client.producer.KafkaProducer
 
unwrap() - Method in interface io.vertx.kafka.client.producer.KafkaWriteStream
 

V

value() - Method in interface io.vertx.kafka.client.consumer.KafkaConsumerRecord
 
value() - Method in interface io.vertx.kafka.client.producer.KafkaProducerRecord
 
VertxSerdes - Class in io.vertx.kafka.client.serialization
 
VertxSerdes() - Constructor for class io.vertx.kafka.client.serialization.VertxSerdes
 
VertxSerdes.BufferSerde - Class in io.vertx.kafka.client.serialization
 
VertxSerdes.JsonArraySerde - Class in io.vertx.kafka.client.serialization
 
VertxSerdes.JsonObjectSerde - Class in io.vertx.kafka.client.serialization
 

W

write(KafkaProducerRecord<K, V>) - Method in interface io.vertx.kafka.client.producer.KafkaProducer
 
write(KafkaProducerRecord<K, V>, Handler<AsyncResult<RecordMetadata>>) - Method in interface io.vertx.kafka.client.producer.KafkaProducer
Asynchronously write a record to a topic
write(ProducerRecord<K, V>, Handler<AsyncResult<RecordMetadata>>) - Method in interface io.vertx.kafka.client.producer.KafkaWriteStream
Asynchronously write a record to a topic
writeQueueFull() - Method in interface io.vertx.kafka.client.producer.KafkaProducer
 
A B C D E F G H I J K L N O P R S T U V W 
Skip navigation links

Copyright © 2018 Eclipse. All rights reserved.