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

A

abortTransaction(Handler<AsyncResult<Void>>) - Method in interface io.vertx.kafka.client.producer.KafkaProducer
Aborts the ongoing transaction.
abortTransaction() - Method in interface io.vertx.kafka.client.producer.KafkaProducer
Like KafkaProducer.abortTransaction(Handler) but with a future of the result
abortTransaction(Handler<AsyncResult<Void>>) - Method in interface io.vertx.kafka.client.producer.KafkaWriteStream
Aborts the ongoing transaction.
abortTransaction() - Method in interface io.vertx.kafka.client.producer.KafkaWriteStream
Like KafkaWriteStream.abortTransaction(Handler) but with a future of the result
addHeader(String, String) - Method in interface io.vertx.kafka.client.producer.KafkaProducerRecord
Like KafkaProducerRecord.addHeader(KafkaHeader) but with a key/value pair
addHeader(String, Buffer) - Method in interface io.vertx.kafka.client.producer.KafkaProducerRecord
Like KafkaProducerRecord.addHeader(KafkaHeader) but with a key/value pair
addHeader(KafkaHeader) - Method in interface io.vertx.kafka.client.producer.KafkaProducerRecord
Add an header to this record.
addHeaders(List<KafkaHeader>) - Method in interface io.vertx.kafka.client.producer.KafkaProducerRecord
Add a list of headers to this record.
addNode(Node) - Method in class io.vertx.kafka.admin.ClusterDescription
Add a node belonging to this cluster to the current node list.
alterConfigs(Map<ConfigResource, Config>, Handler<AsyncResult<Void>>) - Method in interface io.vertx.kafka.admin.KafkaAdminClient
Update the configuration for the specified resources with the default options
alterConfigs(Map<ConfigResource, Config>) - Method in interface io.vertx.kafka.admin.KafkaAdminClient
Like KafkaAdminClient.alterConfigs(Map, Handler) but returns a Future of the asynchronous result
alterConsumerGroupOffsets(String, Map<TopicPartition, OffsetAndMetadata>, Handler<AsyncResult<Void>>) - Method in interface io.vertx.kafka.admin.KafkaAdminClient
Alter committed offsets for a set of partitions in a consumer group.
alterConsumerGroupOffsets(String, Map<TopicPartition, OffsetAndMetadata>) - Method in interface io.vertx.kafka.admin.KafkaAdminClient
Like KafkaAdminClient.alterConsumerGroupOffsets(String, Map, Handler) but returns a Future of the asynchronous result
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() - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
Like KafkaConsumer.assignment(Handler) but returns a Future of the asynchronous result
assignment(Handler<AsyncResult<Set<TopicPartition>>>) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
Get the set of partitions currently assigned to this consumer.
assignment() - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
Like KafkaReadStream.assignment(Handler) but returns a Future of the asynchronous result
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(Set<TopicPartition>) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
Like KafkaConsumer.beginningOffsets(Set, Handler) but returns a Future of the asynchronous result
beginningOffsets(TopicPartition, Handler<AsyncResult<Long>>) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
Get the first offset for the given partitions.
beginningOffsets(TopicPartition) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
Like KafkaConsumer.beginningOffsets(TopicPartition, Handler) but returns a Future of the asynchronous result
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(Set<TopicPartition>) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
Like KafkaReadStream.beginningOffsets(Set, Handler) but returns a Future of the asynchronous result
beginningOffsets(TopicPartition, Handler<AsyncResult<Long>>) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
Get the first offset for the given partition.
beginningOffsets(TopicPartition) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
Like KafkaReadStream.beginningOffsets(TopicPartition, Handler) but returns a Future of the asynchronous result
beginTransaction(Handler<AsyncResult<Void>>) - Method in interface io.vertx.kafka.client.producer.KafkaProducer
Starts a new kafka transaction.
beginTransaction() - Method in interface io.vertx.kafka.client.producer.KafkaProducer
Like KafkaProducer.beginTransaction(Handler) but with a future of the result
beginTransaction(Handler<AsyncResult<Void>>) - Method in interface io.vertx.kafka.client.producer.KafkaWriteStream
Starts a new kafka transaction.
beginTransaction() - Method in interface io.vertx.kafka.client.producer.KafkaWriteStream
Like KafkaWriteStream.beginTransaction(Handler) but with a future of the result
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

checksum() - Method in interface io.vertx.kafka.client.consumer.KafkaConsumerRecord
Deprecated.
As of Kafka 0.11.0. Because of the potential for message format conversion on the broker, the checksum returned by the broker may not match what was computed by the producer. It is therefore unsafe to depend on this checksum for end-to-end delivery guarantees. Additionally, message format v2 does not include a record-level checksum (for performance, the record checksum was replaced with a batch checksum). To maintain compatibility, a partial checksum computed from the record timestamp, serialized key size, and serialized value size is returned instead, but this should not be depended on for end-to-end reliability.
checksum() - Method in class io.vertx.kafka.client.producer.RecordMetadata
Deprecated.
As of Kafka 0.11.0. Because of the potential for message format conversion on the broker, the checksum returned by the broker may not match what was computed by the producer. It is therefore unsafe to depend on this checksum for end-to-end delivery guarantees. Additionally, message format v2 does not include a record-level checksum (for performance, the record checksum was replaced with a batch checksum). To maintain compatibility, a partial checksum computed from the record timestamp, serialized key size, and serialized value size is returned instead, but this should not be depended on for end-to-end reliability.
close(Handler<AsyncResult<Void>>) - Method in interface io.vertx.kafka.admin.KafkaAdminClient
Close the admin client
close() - Method in interface io.vertx.kafka.admin.KafkaAdminClient
Like KafkaAdminClient.close(Handler) but returns a Future of the asynchronous result
close(long, Handler<AsyncResult<Void>>) - Method in interface io.vertx.kafka.admin.KafkaAdminClient
Close the admin client
close(long) - Method in interface io.vertx.kafka.admin.KafkaAdminClient
Like KafkaAdminClient.close(long, Handler) but returns a Future of the asynchronous result
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) - Method in interface io.vertx.kafka.client.producer.KafkaProducer
Like KafkaProducer.close(long, Handler) but returns a Future of the asynchronous result
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(long) - Method in interface io.vertx.kafka.client.producer.KafkaWriteStream
Like KafkaWriteStream.close(long, Handler) but returns a Future of the asynchronous result
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
 
ClusterDescription - Class in io.vertx.kafka.admin
A detailed description of the cluster
ClusterDescription() - Constructor for class io.vertx.kafka.admin.ClusterDescription
Constructor
ClusterDescription(String, Node, List<Node>) - Constructor for class io.vertx.kafka.admin.ClusterDescription
Constructor
ClusterDescription(JsonObject) - Constructor for class io.vertx.kafka.admin.ClusterDescription
Constructor (from JSON representation)
ClusterDescriptionConverter - Class in io.vertx.kafka.admin
Converter and mapper for ClusterDescription.
ClusterDescriptionConverter() - Constructor for class io.vertx.kafka.admin.ClusterDescriptionConverter
 
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) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
Like KafkaConsumer.committed(TopicPartition, Handler) but returns a Future of the asynchronous result
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).
committed(TopicPartition) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
Like KafkaReadStream.committed(TopicPartition, Handler) but returns a Future of the asynchronous result
commitTransaction(Handler<AsyncResult<Void>>) - Method in interface io.vertx.kafka.client.producer.KafkaProducer
Commits the ongoing transaction.
commitTransaction() - Method in interface io.vertx.kafka.client.producer.KafkaProducer
Like KafkaProducer.commitTransaction(Handler) but with a future of the result
commitTransaction(Handler<AsyncResult<Void>>) - Method in interface io.vertx.kafka.client.producer.KafkaWriteStream
Commits the ongoing transaction.
commitTransaction() - Method in interface io.vertx.kafka.client.producer.KafkaWriteStream
Like KafkaWriteStream.commitTransaction(Handler) but with a future of the result
Config - Class in io.vertx.kafka.admin
A configuration object containing the configuration entries for a resource
Config() - Constructor for class io.vertx.kafka.admin.Config
Constructor
Config(List<ConfigEntry>) - Constructor for class io.vertx.kafka.admin.Config
Constructor
Config(JsonObject) - Constructor for class io.vertx.kafka.admin.Config
Constructor (from JSON representation)
ConfigConverter - Class in io.vertx.kafka.admin
Converter and mapper for Config.
ConfigConverter() - Constructor for class io.vertx.kafka.admin.ConfigConverter
 
ConfigEntry - Class in io.vertx.kafka.admin
A class representing a configuration entry containing name, value and additional metadata
ConfigEntry() - Constructor for class io.vertx.kafka.admin.ConfigEntry
Constructor
ConfigEntry(String, String) - Constructor for class io.vertx.kafka.admin.ConfigEntry
Constructor
ConfigEntry(JsonObject) - Constructor for class io.vertx.kafka.admin.ConfigEntry
Constructor (from JSON representation)
ConfigEntryConverter - Class in io.vertx.kafka.admin
Converter and mapper for ConfigEntry.
ConfigEntryConverter() - Constructor for class io.vertx.kafka.admin.ConfigEntryConverter
 
ConfigResource - Class in io.vertx.kafka.client.common
A class representing resources that have configuration
ConfigResource() - Constructor for class io.vertx.kafka.client.common.ConfigResource
Constructor
ConfigResource(ConfigResource.Type, String) - Constructor for class io.vertx.kafka.client.common.ConfigResource
Constructor
ConfigResource(JsonObject) - Constructor for class io.vertx.kafka.client.common.ConfigResource
Constructor (from JSON representation)
ConfigResourceConverter - Class in io.vertx.kafka.client.common
Converter and mapper for ConfigResource.
ConfigResourceConverter() - Constructor for class io.vertx.kafka.client.common.ConfigResourceConverter
 
ConfigSynonym - Class in io.vertx.kafka.admin
Class representing a configuration synonym of a ConfigEntry
ConfigSynonym() - Constructor for class io.vertx.kafka.admin.ConfigSynonym
Constructor
ConfigSynonym(String, String, ConfigEntry.ConfigSource) - Constructor for class io.vertx.kafka.admin.ConfigSynonym
Constructor
ConfigSynonym(JsonObject) - Constructor for class io.vertx.kafka.admin.ConfigSynonym
Constructor (from JSON representation)
ConfigSynonymConverter - Class in io.vertx.kafka.admin
Converter and mapper for ConfigSynonym.
ConfigSynonymConverter() - Constructor for class io.vertx.kafka.admin.ConfigSynonymConverter
 
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
 
ConsumerGroupDescription - Class in io.vertx.kafka.admin
A detailed description of a single consumer group in the cluster
ConsumerGroupDescription() - Constructor for class io.vertx.kafka.admin.ConsumerGroupDescription
Constructor
ConsumerGroupDescription(String, boolean, List<MemberDescription>, String, ConsumerGroupState, Node) - Constructor for class io.vertx.kafka.admin.ConsumerGroupDescription
Constructor
ConsumerGroupDescription(JsonObject) - Constructor for class io.vertx.kafka.admin.ConsumerGroupDescription
Constructor (from JSON representation)
ConsumerGroupDescriptionConverter - Class in io.vertx.kafka.admin
Converter and mapper for ConsumerGroupDescription.
ConsumerGroupDescriptionConverter() - Constructor for class io.vertx.kafka.admin.ConsumerGroupDescriptionConverter
 
ConsumerGroupListing - Class in io.vertx.kafka.admin
A listing of a consumer group in the cluster.
ConsumerGroupListing() - Constructor for class io.vertx.kafka.admin.ConsumerGroupListing
Constructor
ConsumerGroupListing(String, boolean) - Constructor for class io.vertx.kafka.admin.ConsumerGroupListing
Constructor
ConsumerGroupListing(JsonObject) - Constructor for class io.vertx.kafka.admin.ConsumerGroupListing
Constructor (from JSON representation)
ConsumerGroupListingConverter - Class in io.vertx.kafka.admin
Converter and mapper for ConsumerGroupListing.
ConsumerGroupListingConverter() - Constructor for class io.vertx.kafka.admin.ConsumerGroupListingConverter
 
ConsumerTracer<S> - Class in io.vertx.kafka.client.common.tracing
Tracer for Kafka consumer, wrapping the generic tracer.
ConsumerTracer.StartedSpan - Class in io.vertx.kafka.client.common.tracing
 
create(Vertx, AdminClient) - Static method in interface io.vertx.kafka.admin.KafkaAdminClient
Create a new KafkaAdminClient instance
create(Vertx, Map<String, String>) - Static method in interface io.vertx.kafka.admin.KafkaAdminClient
Create a new KafkaAdminClient instance
create(Vertx, Properties) - Static method in interface io.vertx.kafka.admin.KafkaAdminClient
Create a new KafkaAdminClient instance
create(VertxTracer, KafkaClientOptions) - Static method in class io.vertx.kafka.client.common.tracing.ConsumerTracer
Creates a ConsumerTracer, which provides an opinionated facade for using VertxTracer with a Kafka Consumer use case.
create(VertxTracer, KafkaClientOptions) - Static method in class io.vertx.kafka.client.common.tracing.ProducerTracer
Creates a ProducerTracer, which provides an opinionated facade for using VertxTracer with a Kafka Producer use case.
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, Map<String, String>, Deserializer<K>, Deserializer<V>) - Static method in interface io.vertx.kafka.client.consumer.KafkaConsumer
Create a new KafkaConsumer instance
create(Vertx, KafkaClientOptions) - Static method in interface io.vertx.kafka.client.consumer.KafkaConsumer
Create a new KafkaConsumer instance
create(Vertx, KafkaClientOptions, Class<K>, Class<V>) - Static method in interface io.vertx.kafka.client.consumer.KafkaConsumer
Create a new KafkaConsumer instance
create(Vertx, KafkaClientOptions, Deserializer<K>, Deserializer<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, Deserializer<K>, Deserializer<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, Properties, Deserializer<K>, Deserializer<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, Map<String, Object>, Deserializer<K>, Deserializer<V>) - Static method in interface io.vertx.kafka.client.consumer.KafkaReadStream
Create a new KafkaReadStream instance
create(Vertx, KafkaClientOptions) - Static method in interface io.vertx.kafka.client.consumer.KafkaReadStream
Create a new KafkaReadStream instance
create(Vertx, KafkaClientOptions, Class<K>, Class<V>) - Static method in interface io.vertx.kafka.client.consumer.KafkaReadStream
Create a new KafkaReadStream instance
create(Vertx, KafkaClientOptions, Deserializer<K>, Deserializer<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>, Serializer<K>, Serializer<V>) - 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, Serializer<K>, Serializer<V>) - 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, Properties, Serializer<K>, Serializer<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, Map<String, Object>, Serializer<K>, Serializer<V>) - Static method in interface io.vertx.kafka.client.producer.KafkaWriteStream
Create a new KafkaWriteStream instance
create(Vertx, KafkaClientOptions) - Static method in interface io.vertx.kafka.client.producer.KafkaWriteStream
Create a new KafkaWriteStream instance
create(Vertx, KafkaClientOptions, Class<K>, Class<V>) - Static method in interface io.vertx.kafka.client.producer.KafkaWriteStream
Create a new KafkaWriteStream instance
create(Vertx, KafkaClientOptions, Serializer<K>, Serializer<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, KafkaClientOptions) - 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>, Serializer<K>, Serializer<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, 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, Serializer<K>, Serializer<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
createShared(Vertx, String, KafkaClientOptions, Serializer<K>, Serializer<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, KafkaClientOptions, 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
createTopics(List<NewTopic>, Handler<AsyncResult<Void>>) - Method in interface io.vertx.kafka.admin.KafkaAdminClient
Creates a batch of new Kafka topics
createTopics(List<NewTopic>) - Method in interface io.vertx.kafka.admin.KafkaAdminClient
Like KafkaAdminClient.createTopics(List, Handler) but returns a Future of the asynchronous result

D

DEFAULT_MAX_SIZE - Static variable in interface io.vertx.kafka.client.producer.KafkaWriteStream
 
DEFAULT_TRACE_PEER_ADDRESS - Static variable in class io.vertx.kafka.client.common.KafkaClientOptions
Default peer address to set in traces tags is null, and will automatically pick up bootstrap server from config
DEFAULT_TRACING_POLICY - Static variable in class io.vertx.kafka.client.common.KafkaClientOptions
Default tracing policy is 'propagate'
deleteConsumerGroupOffsets(String, Set<TopicPartition>, Handler<AsyncResult<Void>>) - Method in interface io.vertx.kafka.admin.KafkaAdminClient
Delete committed offsets for a set of partitions in a consumer group.
deleteConsumerGroupOffsets(String, Set<TopicPartition>) - Method in interface io.vertx.kafka.admin.KafkaAdminClient
Like KafkaAdminClient.deleteConsumerGroupOffsets(String, Set, Handler) but returns a Future of the asynchronous result
deleteConsumerGroups(List<String>, Handler<AsyncResult<Void>>) - Method in interface io.vertx.kafka.admin.KafkaAdminClient
Delete consumer groups from the cluster.
deleteConsumerGroups(List<String>) - Method in interface io.vertx.kafka.admin.KafkaAdminClient
Like KafkaAdminClient.deleteConsumerGroups(List, Handler) but returns a Future of the asynchronous result
deleteTopics(List<String>, Handler<AsyncResult<Void>>) - Method in interface io.vertx.kafka.admin.KafkaAdminClient
Deletes a batch of Kafka topics
deleteTopics(List<String>) - Method in interface io.vertx.kafka.admin.KafkaAdminClient
Like KafkaAdminClient.deleteTopics(List, Handler) but returns a Future of the asynchronous result
demand() - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
Returns the current demand.
demand() - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
Returns the current demand.
describeCluster(Handler<AsyncResult<ClusterDescription>>) - Method in interface io.vertx.kafka.admin.KafkaAdminClient
Describe the nodes in the cluster with the default options
describeCluster() - Method in interface io.vertx.kafka.admin.KafkaAdminClient
Like KafkaAdminClient.describeCluster(Handler) but returns a Future of the asynchronous result
describeConfigs(List<ConfigResource>, Handler<AsyncResult<Map<ConfigResource, Config>>>) - Method in interface io.vertx.kafka.admin.KafkaAdminClient
Get the configuration for the specified resources with the default options
describeConfigs(List<ConfigResource>) - Method in interface io.vertx.kafka.admin.KafkaAdminClient
Like KafkaAdminClient.describeConfigs(List, Handler) but returns a Future of the asynchronous result
describeConsumerGroups(List<String>, Handler<AsyncResult<Map<String, ConsumerGroupDescription>>>) - Method in interface io.vertx.kafka.admin.KafkaAdminClient
Describe some group ids in the cluster, with the default options
describeConsumerGroups(List<String>) - Method in interface io.vertx.kafka.admin.KafkaAdminClient
Like KafkaAdminClient.describeConsumerGroups(List, Handler) but returns a Future of the asynchronous result
describeTopics(List<String>, Handler<AsyncResult<Map<String, TopicDescription>>>) - Method in interface io.vertx.kafka.admin.KafkaAdminClient
Describe some topics in the cluster, with the default options.
describeTopics(List<String>) - Method in interface io.vertx.kafka.admin.KafkaAdminClient
Like KafkaAdminClient.describeTopics(List, Handler) but returns a Future of the asynchronous result
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
 
drainHandler(Handler<Void>) - Method in interface io.vertx.kafka.client.producer.KafkaWriteStream
 

E

EARLIEST - Static variable in class io.vertx.kafka.admin.OffsetSpec
 
endHandler(Handler<Void>) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
 
endHandler(Handler<Void>) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
 
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(Set<TopicPartition>) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
Like KafkaConsumer.endOffsets(Set, Handler) but returns a Future of the asynchronous result
endOffsets(TopicPartition, Handler<AsyncResult<Long>>) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
Get the last offset for the given partition.
endOffsets(TopicPartition) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
Like KafkaConsumer.endOffsets(TopicPartition, Handler) but returns a Future of the asynchronous result
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(Set<TopicPartition>) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
Like KafkaReadStream.endOffsets(Set, Handler) but returns a Future of the asynchronous result
endOffsets(TopicPartition, Handler<AsyncResult<Long>>) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
Get the last offset for the given partition.
endOffsets(TopicPartition) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
Like KafkaReadStream.endOffsets(TopicPartition, Handler) but returns a Future of the asynchronous result
equals(Object) - Method in class io.vertx.kafka.client.common.ConfigResource
 
equals(Object) - Method in class io.vertx.kafka.client.common.TopicPartition
 
exceptionHandler(Handler<Throwable>) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
 
exceptionHandler(Handler<Throwable>) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
 
exceptionHandler(Handler<Throwable>) - Method in interface io.vertx.kafka.client.producer.KafkaProducer
 
exceptionHandler(Handler<Throwable>) - Method in interface io.vertx.kafka.client.producer.KafkaWriteStream
 

F

fail(Context, Throwable) - Method in class io.vertx.kafka.client.common.tracing.ConsumerTracer.StartedSpan
 
fail(Context, Throwable) - Method in class io.vertx.kafka.client.common.tracing.ProducerTracer.StartedSpan
 
fetch(long) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
 
fetch(long) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
 
finish(Context) - Method in class io.vertx.kafka.client.common.tracing.ConsumerTracer.StartedSpan
 
finish(Context) - Method in class io.vertx.kafka.client.common.tracing.ProducerTracer.StartedSpan
 
flush(Handler<AsyncResult<Void>>) - Method in interface io.vertx.kafka.client.producer.KafkaProducer
Invoking this method makes all buffered records immediately available to write
flush() - Method in interface io.vertx.kafka.client.producer.KafkaProducer
Like KafkaProducer.flush(Handler) but returns a Future of the asynchronous result
flush(Handler<AsyncResult<Void>>) - Method in interface io.vertx.kafka.client.producer.KafkaWriteStream
Invoking this method makes all buffered records immediately available to write
flush() - Method in interface io.vertx.kafka.client.producer.KafkaWriteStream
Like KafkaWriteStream.flush(Handler) but returns a Future of the asynchronous result
fromJson(Iterable<Map.Entry<String, Object>>, ClusterDescription) - Static method in class io.vertx.kafka.admin.ClusterDescriptionConverter
 
fromJson(Iterable<Map.Entry<String, Object>>, Config) - Static method in class io.vertx.kafka.admin.ConfigConverter
 
fromJson(Iterable<Map.Entry<String, Object>>, ConfigEntry) - Static method in class io.vertx.kafka.admin.ConfigEntryConverter
 
fromJson(Iterable<Map.Entry<String, Object>>, ConfigSynonym) - Static method in class io.vertx.kafka.admin.ConfigSynonymConverter
 
fromJson(Iterable<Map.Entry<String, Object>>, ConsumerGroupDescription) - Static method in class io.vertx.kafka.admin.ConsumerGroupDescriptionConverter
 
fromJson(Iterable<Map.Entry<String, Object>>, ConsumerGroupListing) - Static method in class io.vertx.kafka.admin.ConsumerGroupListingConverter
 
fromJson(Iterable<Map.Entry<String, Object>>, ListConsumerGroupOffsetsOptions) - Static method in class io.vertx.kafka.admin.ListConsumerGroupOffsetsOptionsConverter
 
fromJson(Iterable<Map.Entry<String, Object>>, ListOffsetsResultInfo) - Static method in class io.vertx.kafka.admin.ListOffsetsResultInfoConverter
 
fromJson(Iterable<Map.Entry<String, Object>>, MemberAssignment) - Static method in class io.vertx.kafka.admin.MemberAssignmentConverter
 
fromJson(Iterable<Map.Entry<String, Object>>, MemberDescription) - Static method in class io.vertx.kafka.admin.MemberDescriptionConverter
 
fromJson(Iterable<Map.Entry<String, Object>>, NewTopic) - Static method in class io.vertx.kafka.admin.NewTopicConverter
 
fromJson(Iterable<Map.Entry<String, Object>>, OffsetSpec) - Static method in class io.vertx.kafka.admin.OffsetSpecConverter
 
fromJson(Iterable<Map.Entry<String, Object>>, TopicDescription) - Static method in class io.vertx.kafka.admin.TopicDescriptionConverter
 
fromJson(Iterable<Map.Entry<String, Object>>, ConfigResource) - Static method in class io.vertx.kafka.client.common.ConfigResourceConverter
 
fromJson(Iterable<Map.Entry<String, Object>>, KafkaClientOptions) - Static method in class io.vertx.kafka.client.common.KafkaClientOptionsConverter
 
fromJson(Iterable<Map.Entry<String, Object>>, PartitionInfo) - Static method in class io.vertx.kafka.client.common.PartitionInfoConverter
 
fromJson(Iterable<Map.Entry<String, Object>>, TopicPartitionInfo) - Static method in class io.vertx.kafka.client.common.TopicPartitionInfoConverter
 
fromMap(Map<String, Object>, boolean) - Static method in class io.vertx.kafka.client.common.KafkaClientOptions
Create KafkaClientOptions from underlying Kafka config as map
fromProperties(Properties, boolean) - Static method in class io.vertx.kafka.client.common.KafkaClientOptions
Create KafkaClientOptions from underlying Kafka config as Properties

G

getAssignment() - Method in class io.vertx.kafka.admin.MemberDescription
 
getClientId() - Method in class io.vertx.kafka.admin.MemberDescription
 
getClusterId() - Method in class io.vertx.kafka.admin.ClusterDescription
 
getConfig() - Method in class io.vertx.kafka.admin.NewTopic
 
getConfig() - Method in class io.vertx.kafka.client.common.KafkaClientOptions
 
getConsumerId() - Method in class io.vertx.kafka.admin.MemberDescription
 
getController() - Method in class io.vertx.kafka.admin.ClusterDescription
 
getCoordinator() - Method in class io.vertx.kafka.admin.ConsumerGroupDescription
 
getEntries() - Method in class io.vertx.kafka.admin.Config
 
getGroupId() - Method in class io.vertx.kafka.admin.ConsumerGroupDescription
 
getGroupId() - Method in class io.vertx.kafka.admin.ConsumerGroupListing
 
getHost() - Method in class io.vertx.kafka.admin.MemberDescription
 
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
 
getIsr() - Method in class io.vertx.kafka.client.common.TopicPartitionInfo
 
getLeader() - Method in class io.vertx.kafka.client.common.PartitionInfo
 
getLeader() - Method in class io.vertx.kafka.client.common.TopicPartitionInfo
 
getLeaderEpoch() - Method in class io.vertx.kafka.admin.ListOffsetsResultInfo
 
getMembers() - Method in class io.vertx.kafka.admin.ConsumerGroupDescription
 
getMetadata() - Method in class io.vertx.kafka.client.consumer.OffsetAndMetadata
 
getName() - Method in class io.vertx.kafka.admin.ConfigEntry
 
getName() - Method in class io.vertx.kafka.admin.ConfigSynonym
 
getName() - Method in class io.vertx.kafka.admin.NewTopic
 
getName() - Method in class io.vertx.kafka.admin.TopicDescription
 
getName() - Method in class io.vertx.kafka.client.common.ConfigResource
 
getNodes() - Method in class io.vertx.kafka.admin.ClusterDescription
 
getNumPartitions() - Method in class io.vertx.kafka.admin.NewTopic
 
getOffset() - Method in class io.vertx.kafka.admin.ListOffsetsResultInfo
 
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.common.TopicPartitionInfo
 
getPartition() - Method in class io.vertx.kafka.client.producer.RecordMetadata
 
getPartitionAssignor() - Method in class io.vertx.kafka.admin.ConsumerGroupDescription
 
getPartitions() - Method in class io.vertx.kafka.admin.TopicDescription
 
getPort() - Method in class io.vertx.kafka.client.common.Node
 
getReplicas() - Method in class io.vertx.kafka.client.common.PartitionInfo
 
getReplicas() - Method in class io.vertx.kafka.client.common.TopicPartitionInfo
 
getReplicasAssignments() - Method in class io.vertx.kafka.admin.NewTopic
 
getReplicationFactor() - Method in class io.vertx.kafka.admin.NewTopic
 
getSource() - Method in class io.vertx.kafka.admin.ConfigEntry
 
getSource() - Method in class io.vertx.kafka.admin.ConfigSynonym
 
getSpec() - Method in class io.vertx.kafka.admin.OffsetSpec
 
getState() - Method in class io.vertx.kafka.admin.ConsumerGroupDescription
 
getSynonyms() - Method in class io.vertx.kafka.admin.ConfigEntry
 
getTimestamp() - Method in class io.vertx.kafka.admin.ListOffsetsResultInfo
 
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
 
getTopicPartitions() - Method in class io.vertx.kafka.admin.MemberAssignment
 
getTracePeerAddress() - Method in class io.vertx.kafka.client.common.KafkaClientOptions
 
getTracingPolicy() - Method in class io.vertx.kafka.client.common.KafkaClientOptions
 
getType() - Method in class io.vertx.kafka.client.common.ConfigResource
 
getValue() - Method in class io.vertx.kafka.admin.ConfigEntry
 
getValue() - Method in class io.vertx.kafka.admin.ConfigSynonym
 

H

handler(Handler<KafkaConsumerRecord<K, V>>) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
 
handler(Handler<ConsumerRecord<K, V>>) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
 
hashCode() - Method in class io.vertx.kafka.client.common.ConfigResource
 
hashCode() - Method in class io.vertx.kafka.client.common.TopicPartition
 
hasRack() - Method in class io.vertx.kafka.client.common.Node
 
header(String, Buffer) - Static method in interface io.vertx.kafka.client.producer.KafkaHeader
 
header(String, String) - Static method in interface io.vertx.kafka.client.producer.KafkaHeader
 
header(String, byte[]) - Static method in interface io.vertx.kafka.client.producer.KafkaHeader
 
headers() - Method in interface io.vertx.kafka.client.consumer.KafkaConsumerRecord
 
headers() - Method in interface io.vertx.kafka.client.producer.KafkaProducerRecord
 

I

initTransactions(Handler<AsyncResult<Void>>) - Method in interface io.vertx.kafka.client.producer.KafkaProducer
Initializes the underlying kafka transactional producer.
initTransactions() - Method in interface io.vertx.kafka.client.producer.KafkaProducer
Like KafkaProducer.initTransactions(Handler) but with a future of the result
initTransactions(Handler<AsyncResult<Void>>) - Method in interface io.vertx.kafka.client.producer.KafkaWriteStream
Initializes the underlying kafka transactional producer.
initTransactions() - Method in interface io.vertx.kafka.client.producer.KafkaWriteStream
Like KafkaWriteStream.initTransactions(Handler) but with a future of the result
io.vertx.kafka.admin - package io.vertx.kafka.admin
 
io.vertx.kafka.client.common - package io.vertx.kafka.client.common
 
io.vertx.kafka.client.common.tracing - package io.vertx.kafka.client.common.tracing
 
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
 
isDefault() - Method in class io.vertx.kafka.admin.ConfigEntry
 
isDefault() - Method in class io.vertx.kafka.client.common.ConfigResource
 
isEmpty() - Method in class io.vertx.kafka.client.common.Node
 
isEmpty() - Method in interface io.vertx.kafka.client.consumer.KafkaConsumerRecords
 
isInternal() - Method in class io.vertx.kafka.admin.TopicDescription
 
isReadOnly() - Method in class io.vertx.kafka.admin.ConfigEntry
 
isSensitive() - Method in class io.vertx.kafka.admin.ConfigEntry
 
isSimpleConsumerGroup() - Method in class io.vertx.kafka.admin.ConsumerGroupDescription
 
isSimpleConsumerGroup() - Method in class io.vertx.kafka.admin.ConsumerGroupListing
 

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

KafkaAdminClient - Interface in io.vertx.kafka.admin
Vert.x Kafka Admin client implementation
KafkaClientOptions - Class in io.vertx.kafka.client.common
Generic KafkaClient options.
KafkaClientOptions() - Constructor for class io.vertx.kafka.client.common.KafkaClientOptions
 
KafkaClientOptions(JsonObject) - Constructor for class io.vertx.kafka.client.common.KafkaClientOptions
 
KafkaClientOptionsConverter - Class in io.vertx.kafka.client.common
Converter and mapper for KafkaClientOptions.
KafkaClientOptionsConverter() - Constructor for class io.vertx.kafka.client.common.KafkaClientOptionsConverter
 
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
KafkaHeader - Interface in io.vertx.kafka.client.producer
Vert.x Kafka producer record header.
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.KafkaHeader
 
key() - Method in interface io.vertx.kafka.client.producer.KafkaProducerRecord
 

L

LATEST - Static variable in class io.vertx.kafka.admin.OffsetSpec
 
listConsumerGroupOffsets(String, ListConsumerGroupOffsetsOptions, Handler<AsyncResult<Map<TopicPartition, OffsetAndMetadata>>>) - Method in interface io.vertx.kafka.admin.KafkaAdminClient
List the consumer group offsets available in the cluster.
listConsumerGroupOffsets(String, ListConsumerGroupOffsetsOptions) - Method in interface io.vertx.kafka.admin.KafkaAdminClient
listConsumerGroupOffsets(String, Handler<AsyncResult<Map<TopicPartition, OffsetAndMetadata>>>) - Method in interface io.vertx.kafka.admin.KafkaAdminClient
List the consumer group offsets available in the cluster.
listConsumerGroupOffsets(String) - Method in interface io.vertx.kafka.admin.KafkaAdminClient
Like KafkaAdminClient.listConsumerGroupOffsets(String, Handler) but returns a Future of the asynchronous result
ListConsumerGroupOffsetsOptions - Class in io.vertx.kafka.admin
 
ListConsumerGroupOffsetsOptions() - Constructor for class io.vertx.kafka.admin.ListConsumerGroupOffsetsOptions
Constructor
ListConsumerGroupOffsetsOptions(JsonObject) - Constructor for class io.vertx.kafka.admin.ListConsumerGroupOffsetsOptions
Constructor (from JSON representation)
ListConsumerGroupOffsetsOptionsConverter - Class in io.vertx.kafka.admin
Converter and mapper for ListConsumerGroupOffsetsOptions.
ListConsumerGroupOffsetsOptionsConverter() - Constructor for class io.vertx.kafka.admin.ListConsumerGroupOffsetsOptionsConverter
 
listConsumerGroups(Handler<AsyncResult<List<ConsumerGroupListing>>>) - Method in interface io.vertx.kafka.admin.KafkaAdminClient
Get the the consumer groups available in the cluster with the default options
listConsumerGroups() - Method in interface io.vertx.kafka.admin.KafkaAdminClient
Like KafkaAdminClient.listConsumerGroups(Handler) but returns a Future of the asynchronous result
listOffsets(Map<TopicPartition, OffsetSpec>, Handler<AsyncResult<Map<TopicPartition, ListOffsetsResultInfo>>>) - Method in interface io.vertx.kafka.admin.KafkaAdminClient
List the offsets available for a set of partitions.
listOffsets(Map<TopicPartition, OffsetSpec>) - Method in interface io.vertx.kafka.admin.KafkaAdminClient
Like #listOffsets(Map, Handler) but returns a Future of the asynchronous result
ListOffsetsResultInfo - Class in io.vertx.kafka.admin
 
ListOffsetsResultInfo(long, long, Integer) - Constructor for class io.vertx.kafka.admin.ListOffsetsResultInfo
Constructor
ListOffsetsResultInfo(JsonObject) - Constructor for class io.vertx.kafka.admin.ListOffsetsResultInfo
Constructor (from JSON representation)
ListOffsetsResultInfoConverter - Class in io.vertx.kafka.admin
Converter and mapper for ListOffsetsResultInfo.
ListOffsetsResultInfoConverter() - Constructor for class io.vertx.kafka.admin.ListOffsetsResultInfoConverter
 
listTopics(Handler<AsyncResult<Set<String>>>) - Method in interface io.vertx.kafka.admin.KafkaAdminClient
List the topics available in the cluster with the default options.
listTopics() - Method in interface io.vertx.kafka.admin.KafkaAdminClient
Like KafkaAdminClient.listTopics(Handler) but returns a Future of the asynchronous result
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() - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
Like KafkaConsumer.listTopics(Handler) but returns a Future of the asynchronous result
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.
listTopics() - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
Like KafkaReadStream.listTopics(Handler) but returns a Future of the asynchronous result

M

MemberAssignment - Class in io.vertx.kafka.admin
A description of the assignments of a specific group member
MemberAssignment() - Constructor for class io.vertx.kafka.admin.MemberAssignment
Constructor
MemberAssignment(Set<TopicPartition>) - Constructor for class io.vertx.kafka.admin.MemberAssignment
Constructor
MemberAssignment(JsonObject) - Constructor for class io.vertx.kafka.admin.MemberAssignment
Constructor (from JSON representation)
MemberAssignmentConverter - Class in io.vertx.kafka.admin
Converter and mapper for MemberAssignment.
MemberAssignmentConverter() - Constructor for class io.vertx.kafka.admin.MemberAssignmentConverter
 
MemberDescription - Class in io.vertx.kafka.admin
A detailed description of a single group instance in the cluster
MemberDescription() - Constructor for class io.vertx.kafka.admin.MemberDescription
Constructor
MemberDescription(String, String, String, MemberAssignment) - Constructor for class io.vertx.kafka.admin.MemberDescription
Constructor
MemberDescription(JsonObject) - Constructor for class io.vertx.kafka.admin.MemberDescription
Constructor (from JSON representation)
MemberDescriptionConverter - Class in io.vertx.kafka.admin
Converter and mapper for MemberDescription.
MemberDescriptionConverter() - Constructor for class io.vertx.kafka.admin.MemberDescriptionConverter
 

N

NewTopic - Class in io.vertx.kafka.admin
A new topic to be created
NewTopic() - Constructor for class io.vertx.kafka.admin.NewTopic
Constructor
NewTopic(String, int, short) - Constructor for class io.vertx.kafka.admin.NewTopic
Constructor
NewTopic(String, Map<Integer, List<Integer>>) - Constructor for class io.vertx.kafka.admin.NewTopic
Constructor
NewTopic(JsonObject) - Constructor for class io.vertx.kafka.admin.NewTopic
Constructor (from JSON representation)
NewTopicConverter - Class in io.vertx.kafka.admin
Converter and mapper for NewTopic.
NewTopicConverter() - Constructor for class io.vertx.kafka.admin.NewTopicConverter
 
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(Map<TopicPartition, Long>) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
Like KafkaConsumer.offsetsForTimes(Map, Handler) but returns a Future of the asynchronous result
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(TopicPartition, Long) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
Like KafkaConsumer.offsetsForTimes(TopicPartition, Long, Handler) but returns a Future of the asynchronous result
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(Map<TopicPartition, Long>) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
Like KafkaReadStream.offsetsForTimes(Map, Handler) but returns a Future of the asynchronous result
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.
offsetsForTimes(TopicPartition, long) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
Like KafkaReadStream.offsetsForTimes(TopicPartition, long, Handler) but returns a Future of the asynchronous result
OffsetSpec - Class in io.vertx.kafka.admin
 
OffsetSpec(long) - Constructor for class io.vertx.kafka.admin.OffsetSpec
Constructor
OffsetSpec(JsonObject) - Constructor for class io.vertx.kafka.admin.OffsetSpec
Constructor (from JSON representation)
OffsetSpecConverter - Class in io.vertx.kafka.admin
Converter and mapper for OffsetSpec.
OffsetSpecConverter() - Constructor for class io.vertx.kafka.admin.OffsetSpecConverter
 

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 and mapper 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) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
Like KafkaConsumer.partitionsFor(String, Handler) but returns a Future of the asynchronous result
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) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
Like KafkaReadStream.partitionsFor(String, Handler) but returns a Future of the asynchronous result
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) - Method in interface io.vertx.kafka.client.producer.KafkaProducer
Like KafkaProducer.partitionsFor(String, Handler) but returns a Future of the asynchronous result
partitionsFor(String, Handler<AsyncResult<List<PartitionInfo>>>) - Method in interface io.vertx.kafka.client.producer.KafkaWriteStream
Get the partition metadata for the give topic.
partitionsFor(String) - Method in interface io.vertx.kafka.client.producer.KafkaWriteStream
Like KafkaWriteStream.partitionsFor(String, Handler) but returns a Future of the asynchronous result
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() - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
 
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() - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
Like KafkaConsumer.paused(Handler) but returns a Future of the asynchronous result
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).
paused() - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
Like KafkaReadStream.paused(Handler) but returns a Future of the asynchronous result
poll(Duration, Handler<AsyncResult<KafkaConsumerRecords<K, V>>>) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
Executes a poll for getting messages from Kafka.
poll(Duration) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
Like KafkaConsumer.poll(Duration, Handler) but returns a Future of the asynchronous result
poll(Duration, Handler<AsyncResult<ConsumerRecords<K, V>>>) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
Executes a poll for getting messages from Kafka.
poll(Duration) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
Like KafkaReadStream.poll(Duration, Handler) but returns a Future of the asynchronous result
pollTimeout(Duration) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
Sets the poll timeout for the underlying native Kafka Consumer.
pollTimeout(Duration) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
Sets the poll timeout 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) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
Like KafkaConsumer.position(TopicPartition, Handler) but returns a Future of the asynchronous result
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).
position(TopicPartition) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
Like KafkaReadStream.position(TopicPartition, Handler) but returns a Future of the asynchronous result
prepareMessageReceived(Context, ConsumerRecord) - Method in class io.vertx.kafka.client.common.tracing.ConsumerTracer
 
prepareSendMessage(Context, ProducerRecord) - Method in class io.vertx.kafka.client.common.tracing.ProducerTracer
 
ProducerTracer<S> - Class in io.vertx.kafka.client.common.tracing
Tracer for Kafka producer, wrapping the generic tracer.
ProducerTracer.StartedSpan - Class in io.vertx.kafka.client.common.tracing
 

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() - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
 
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.
send(KafkaProducerRecord<K, V>) - Method in interface io.vertx.kafka.client.producer.KafkaProducer
Asynchronously write a record to a topic
send(KafkaProducerRecord<K, V>, Handler<AsyncResult<RecordMetadata>>) - Method in interface io.vertx.kafka.client.producer.KafkaProducer
Asynchronously write a record to a topic
send(ProducerRecord<K, V>) - Method in interface io.vertx.kafka.client.producer.KafkaWriteStream
Asynchronously write a record to a topic
send(ProducerRecord<K, V>, Handler<AsyncResult<RecordMetadata>>) - Method in interface io.vertx.kafka.client.producer.KafkaWriteStream
Asynchronously write a record to a topic
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
 
setAssignment(MemberAssignment) - Method in class io.vertx.kafka.admin.MemberDescription
Set the assignment of the group member
setChecksum(long) - Method in class io.vertx.kafka.client.producer.RecordMetadata
Set the checksum (CRC32) of the record.
setClientId(String) - Method in class io.vertx.kafka.admin.MemberDescription
Set the client id of the group member
setClusterId(String) - Method in class io.vertx.kafka.admin.ClusterDescription
Set the cluster ID
setConfig(Map<String, String>) - Method in class io.vertx.kafka.admin.NewTopic
Set the configuration for the new topic or null if no configs ever specified
setConfig(Map<String, Object>) - Method in class io.vertx.kafka.client.common.KafkaClientOptions
Set the Kafka config.
setConfig(String, Object) - Method in class io.vertx.kafka.client.common.KafkaClientOptions
Set a Kafka config entry.
setConsumerId(String) - Method in class io.vertx.kafka.admin.MemberDescription
Set the consumer id of the group member
setController(Node) - Method in class io.vertx.kafka.admin.ClusterDescription
Set the controller node.
setCoordinator(Node) - Method in class io.vertx.kafka.admin.ConsumerGroupDescription
Set the consumer group coordinator, or null if the coordinator is not known
setDefault(boolean) - Method in class io.vertx.kafka.admin.ConfigEntry
Set whether the config value is the default or if it's been explicitly set
setDefault(boolean) - Method in class io.vertx.kafka.client.common.ConfigResource
Set if this is the default resource of a resource type.
setEntries(List<ConfigEntry>) - Method in class io.vertx.kafka.admin.Config
Set the configuration entries for a resource
setGroupId(String) - Method in class io.vertx.kafka.admin.ConsumerGroupDescription
Set the id of the consumer group
setGroupId(String) - Method in class io.vertx.kafka.admin.ConsumerGroupListing
Set the consumer group id
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.admin.MemberDescription
Set the host where the group member is running
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
setInternal(boolean) - Method in class io.vertx.kafka.admin.TopicDescription
Set whether the topic is internal to Kafka.
setIsEmpty(boolean) - Method in class io.vertx.kafka.client.common.Node
Set if this node is empty
setIsr(List<Node>) - Method in class io.vertx.kafka.client.common.TopicPartitionInfo
Set the subset of the replicas that are in sync
setLeader(Node) - Method in class io.vertx.kafka.client.common.PartitionInfo
Set the node id of the node currently acting as a leader
setLeader(Node) - Method in class io.vertx.kafka.client.common.TopicPartitionInfo
Set the node id of the node currently acting as a leader
setLeaderEpoch(Integer) - Method in class io.vertx.kafka.admin.ListOffsetsResultInfo
Set the leader epoch
setMembers(List<MemberDescription>) - Method in class io.vertx.kafka.admin.ConsumerGroupDescription
Set a list of the members of the consumer group
setMetadata(String) - Method in class io.vertx.kafka.client.consumer.OffsetAndMetadata
Set additional metadata for the offset committed
setName(String) - Method in class io.vertx.kafka.admin.ConfigEntry
Set the config name
setName(String) - Method in class io.vertx.kafka.admin.ConfigSynonym
Set the name of this configuration
setName(String) - Method in class io.vertx.kafka.admin.NewTopic
Set the name of the topic to be created
setName(String) - Method in class io.vertx.kafka.admin.TopicDescription
Set the name of the topic.
setName(String) - Method in class io.vertx.kafka.client.common.ConfigResource
Set the resource name
setNodes(List<Node>) - Method in class io.vertx.kafka.admin.ClusterDescription
Set the nodes belonging to this cluster
setNumPartitions(int) - Method in class io.vertx.kafka.admin.NewTopic
Set the number of partitions for the new topic or -1 if a replica assignment has been specified
setOffset(long) - Method in class io.vertx.kafka.admin.ListOffsetsResultInfo
Set the offset
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.common.TopicPartitionInfo
Set the partition id
setPartition(int) - Method in class io.vertx.kafka.client.producer.RecordMetadata
Set the partition the record was sent to
setPartitionAssignor(String) - Method in class io.vertx.kafka.admin.ConsumerGroupDescription
Set the consumer group partition assignor
setPartitions(List<TopicPartitionInfo>) - Method in class io.vertx.kafka.admin.TopicDescription
Set A list of partitions where the index represents the partition id and the element contains leadership and replica information for that partition.
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
setReadOnly(boolean) - Method in class io.vertx.kafka.admin.ConfigEntry
Set whether the config is read-only and cannot be updated
setReplicas(List<Node>) - Method in class io.vertx.kafka.client.common.PartitionInfo
Set the complete set of replicas for this partition
setReplicas(List<Node>) - Method in class io.vertx.kafka.client.common.TopicPartitionInfo
Set the complete set of replicas for this partition
setReplicasAssignments(Map<Integer, List<Integer>>) - Method in class io.vertx.kafka.admin.NewTopic
Set a map from partition id to replica ids
setReplicationFactor(short) - Method in class io.vertx.kafka.admin.NewTopic
Set the replication factor for the new topic or -1 if a replica assignment has been specified
setSensitive(boolean) - Method in class io.vertx.kafka.admin.ConfigEntry
Set whether the config value is sensitive.
setSimpleConsumerGroup(boolean) - Method in class io.vertx.kafka.admin.ConsumerGroupDescription
Set if consumer group is simple or not
setSimpleConsumerGroup(boolean) - Method in class io.vertx.kafka.admin.ConsumerGroupListing
Set if consumer group is simple or not
setSource(ConfigEntry.ConfigSource) - Method in class io.vertx.kafka.admin.ConfigEntry
Set the source of this configuration entry
setSource(ConfigEntry.ConfigSource) - Method in class io.vertx.kafka.admin.ConfigSynonym
Set the source of this configuration
setSpec(long) - Method in class io.vertx.kafka.admin.OffsetSpec
Set the offset spec
setState(ConsumerGroupState) - Method in class io.vertx.kafka.admin.ConsumerGroupDescription
Set the consumer group state, or UNKNOWN if the state is too new for us to parse
setSynonyms(List<ConfigSynonym>) - Method in class io.vertx.kafka.admin.ConfigEntry
Set all config values that may be used as the value of this config along with their source, in the order of precedence
setTimestamp(long) - Method in class io.vertx.kafka.admin.ListOffsetsResultInfo
Set the timestamp
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
setTopicPartitions(Set<TopicPartition>) - Method in class io.vertx.kafka.admin.MemberAssignment
Set the list of topic partitions
setTracePeerAddress(String) - Method in class io.vertx.kafka.client.common.KafkaClientOptions
Set the Kafka address to show in trace tags.
setTracingPolicy(TracingPolicy) - Method in class io.vertx.kafka.client.common.KafkaClientOptions
Set the Kafka tracing policy.
setType(ConfigResource.Type) - Method in class io.vertx.kafka.client.common.ConfigResource
Set the resource type
setValue(String) - Method in class io.vertx.kafka.admin.ConfigEntry
Set the value or null.
setValue(String) - Method in class io.vertx.kafka.admin.ConfigSynonym
Set the value of this configuration, which may be null if the configuration is sensitive
setWriteQueueMaxSize(int) - Method in interface io.vertx.kafka.client.producer.KafkaProducer
 
setWriteQueueMaxSize(int) - Method in interface io.vertx.kafka.client.producer.KafkaWriteStream
 
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(Pattern) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
Subscribe to all topics matching specified pattern to get dynamically assigned partitions.
subscribe(Pattern, Handler<AsyncResult<Void>>) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
Subscribe to all topics matching specified pattern 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.
subscribe(Pattern, Handler<AsyncResult<Void>>) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
Subscribe to all topics matching specified pattern to get dynamically assigned partitions.
subscribe(Pattern) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
Subscribe to all topics matching specified pattern to get dynamically assigned partitions.
subscription(Handler<AsyncResult<Set<String>>>) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
Get the current subscription.
subscription() - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
Like KafkaConsumer.subscription(Handler) but returns a Future of the asynchronous result
subscription(Handler<AsyncResult<Set<String>>>) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
Get the current subscription.
subscription() - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
Like KafkaReadStream.subscription(Handler) but returns a Future of the asynchronous result

T

TIMESTAMP(long) - Static method in class io.vertx.kafka.admin.OffsetSpec
 
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.admin.ClusterDescription
Convert object to JSON representation
toJson(ClusterDescription, JsonObject) - Static method in class io.vertx.kafka.admin.ClusterDescriptionConverter
 
toJson(ClusterDescription, Map<String, Object>) - Static method in class io.vertx.kafka.admin.ClusterDescriptionConverter
 
toJson() - Method in class io.vertx.kafka.admin.Config
Convert object to JSON representation
toJson(Config, JsonObject) - Static method in class io.vertx.kafka.admin.ConfigConverter
 
toJson(Config, Map<String, Object>) - Static method in class io.vertx.kafka.admin.ConfigConverter
 
toJson() - Method in class io.vertx.kafka.admin.ConfigEntry
Convert object to JSON representation
toJson(ConfigEntry, JsonObject) - Static method in class io.vertx.kafka.admin.ConfigEntryConverter
 
toJson(ConfigEntry, Map<String, Object>) - Static method in class io.vertx.kafka.admin.ConfigEntryConverter
 
toJson() - Method in class io.vertx.kafka.admin.ConfigSynonym
Convert object to JSON representation
toJson(ConfigSynonym, JsonObject) - Static method in class io.vertx.kafka.admin.ConfigSynonymConverter
 
toJson(ConfigSynonym, Map<String, Object>) - Static method in class io.vertx.kafka.admin.ConfigSynonymConverter
 
toJson() - Method in class io.vertx.kafka.admin.ConsumerGroupDescription
Convert object to JSON representation
toJson(ConsumerGroupDescription, JsonObject) - Static method in class io.vertx.kafka.admin.ConsumerGroupDescriptionConverter
 
toJson(ConsumerGroupDescription, Map<String, Object>) - Static method in class io.vertx.kafka.admin.ConsumerGroupDescriptionConverter
 
toJson() - Method in class io.vertx.kafka.admin.ConsumerGroupListing
Convert object to JSON representation
toJson(ConsumerGroupListing, JsonObject) - Static method in class io.vertx.kafka.admin.ConsumerGroupListingConverter
 
toJson(ConsumerGroupListing, Map<String, Object>) - Static method in class io.vertx.kafka.admin.ConsumerGroupListingConverter
 
toJson() - Method in class io.vertx.kafka.admin.ListConsumerGroupOffsetsOptions
Convert object to JSON representation
toJson(ListConsumerGroupOffsetsOptions, JsonObject) - Static method in class io.vertx.kafka.admin.ListConsumerGroupOffsetsOptionsConverter
 
toJson(ListConsumerGroupOffsetsOptions, Map<String, Object>) - Static method in class io.vertx.kafka.admin.ListConsumerGroupOffsetsOptionsConverter
 
toJson() - Method in class io.vertx.kafka.admin.ListOffsetsResultInfo
Convert object to JSON representation
toJson(ListOffsetsResultInfo, JsonObject) - Static method in class io.vertx.kafka.admin.ListOffsetsResultInfoConverter
 
toJson(ListOffsetsResultInfo, Map<String, Object>) - Static method in class io.vertx.kafka.admin.ListOffsetsResultInfoConverter
 
toJson() - Method in class io.vertx.kafka.admin.MemberAssignment
Convert object to JSON representation
toJson(MemberAssignment, JsonObject) - Static method in class io.vertx.kafka.admin.MemberAssignmentConverter
 
toJson(MemberAssignment, Map<String, Object>) - Static method in class io.vertx.kafka.admin.MemberAssignmentConverter
 
toJson() - Method in class io.vertx.kafka.admin.MemberDescription
Convert object to JSON representation
toJson(MemberDescription, JsonObject) - Static method in class io.vertx.kafka.admin.MemberDescriptionConverter
 
toJson(MemberDescription, Map<String, Object>) - Static method in class io.vertx.kafka.admin.MemberDescriptionConverter
 
toJson() - Method in class io.vertx.kafka.admin.NewTopic
Convert object to JSON representation
toJson(NewTopic, JsonObject) - Static method in class io.vertx.kafka.admin.NewTopicConverter
 
toJson(NewTopic, Map<String, Object>) - Static method in class io.vertx.kafka.admin.NewTopicConverter
 
toJson() - Method in class io.vertx.kafka.admin.OffsetSpec
Convert object to JSON representation
toJson(OffsetSpec, JsonObject) - Static method in class io.vertx.kafka.admin.OffsetSpecConverter
 
toJson(OffsetSpec, Map<String, Object>) - Static method in class io.vertx.kafka.admin.OffsetSpecConverter
 
toJson() - Method in class io.vertx.kafka.admin.TopicDescription
Convert object to JSON representation
toJson(TopicDescription, JsonObject) - Static method in class io.vertx.kafka.admin.TopicDescriptionConverter
 
toJson(TopicDescription, Map<String, Object>) - Static method in class io.vertx.kafka.admin.TopicDescriptionConverter
 
toJson() - Method in class io.vertx.kafka.client.common.ConfigResource
Convert object to JSON representation
toJson(ConfigResource, JsonObject) - Static method in class io.vertx.kafka.client.common.ConfigResourceConverter
 
toJson(ConfigResource, Map<String, Object>) - Static method in class io.vertx.kafka.client.common.ConfigResourceConverter
 
toJson() - Method in class io.vertx.kafka.client.common.KafkaClientOptions
 
toJson(KafkaClientOptions, JsonObject) - Static method in class io.vertx.kafka.client.common.KafkaClientOptionsConverter
 
toJson(KafkaClientOptions, Map<String, Object>) - Static method in class io.vertx.kafka.client.common.KafkaClientOptionsConverter
 
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(PartitionInfo, Map<String, Object>) - 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.common.TopicPartitionInfo
Convert object to JSON representation
toJson(TopicPartitionInfo, JsonObject) - Static method in class io.vertx.kafka.client.common.TopicPartitionInfoConverter
 
toJson(TopicPartitionInfo, Map<String, Object>) - Static method in class io.vertx.kafka.client.common.TopicPartitionInfoConverter
 
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
 
TopicDescription - Class in io.vertx.kafka.admin
A detailed description of a single topic in the cluster
TopicDescription() - Constructor for class io.vertx.kafka.admin.TopicDescription
Constructor
TopicDescription(boolean, String, List<TopicPartitionInfo>) - Constructor for class io.vertx.kafka.admin.TopicDescription
Constructor
TopicDescription(JsonObject) - Constructor for class io.vertx.kafka.admin.TopicDescription
Constructor (from JSON representation)
TopicDescriptionConverter - Class in io.vertx.kafka.admin
Converter and mapper for TopicDescription.
TopicDescriptionConverter() - Constructor for class io.vertx.kafka.admin.TopicDescriptionConverter
 
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)
TopicPartitionInfo - Class in io.vertx.kafka.client.common
A class containing leadership, replicas and ISR information for a topic partition.
TopicPartitionInfo() - Constructor for class io.vertx.kafka.client.common.TopicPartitionInfo
Constructor
TopicPartitionInfo(List<Node>, Node, int, List<Node>) - Constructor for class io.vertx.kafka.client.common.TopicPartitionInfo
Constructor
TopicPartitionInfo(JsonObject) - Constructor for class io.vertx.kafka.client.common.TopicPartitionInfo
Constructor (from JSON representation)
TopicPartitionInfoConverter - Class in io.vertx.kafka.client.common
Converter and mapper for TopicPartitionInfo.
TopicPartitionInfoConverter() - Constructor for class io.vertx.kafka.client.common.TopicPartitionInfoConverter
 
topicPartitions(List<TopicPartition>) - Method in class io.vertx.kafka.admin.ListConsumerGroupOffsetsOptions
Set the topic partitions to list as part of the result.
topicPartitions() - Method in class io.vertx.kafka.admin.ListConsumerGroupOffsetsOptions
Returns a list of topic partitions to add as part of the result.
toString() - Method in class io.vertx.kafka.admin.ClusterDescription
 
toString() - Method in class io.vertx.kafka.admin.Config
 
toString() - Method in class io.vertx.kafka.admin.ConfigEntry
 
toString() - Method in class io.vertx.kafka.admin.ConfigSynonym
 
toString() - Method in class io.vertx.kafka.admin.ConsumerGroupDescription
 
toString() - Method in class io.vertx.kafka.admin.ConsumerGroupListing
 
toString() - Method in class io.vertx.kafka.admin.ListConsumerGroupOffsetsOptions
 
toString() - Method in class io.vertx.kafka.admin.ListOffsetsResultInfo
 
toString() - Method in class io.vertx.kafka.admin.MemberAssignment
 
toString() - Method in class io.vertx.kafka.admin.MemberDescription
 
toString() - Method in class io.vertx.kafka.admin.NewTopic
 
toString() - Method in class io.vertx.kafka.admin.OffsetSpec
 
toString() - Method in class io.vertx.kafka.admin.TopicDescription
 
toString() - Method in class io.vertx.kafka.client.common.ConfigResource
 
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.common.TopicPartitionInfo
 
toString() - Method in class io.vertx.kafka.client.consumer.OffsetAndMetadata
 
toString() - Method in class io.vertx.kafka.client.consumer.OffsetAndTimestamp
 
TraceTags - Enum in io.vertx.kafka.client.common.tracing
Tags for Kafka Tracing

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.KafkaHeader
 
value() - Method in interface io.vertx.kafka.client.producer.KafkaProducerRecord
 
valueOf(String) - Static method in enum io.vertx.kafka.client.common.tracing.TraceTags
Returns the enum constant of this type with the specified name.
values() - Static method in enum io.vertx.kafka.client.common.tracing.TraceTags
Returns an array containing the constants of this enum type, in the order they are declared.
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
 
A B C D E F G H I J K L M N O P R S T U V 
Skip navigation links

Copyright © 2021 Eclipse. All rights reserved.