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

A

abortTransaction() - Method in interface io.vertx.kafka.client.producer.KafkaProducer
Aborts the ongoing transaction.
abortTransaction() - Method in interface io.vertx.kafka.client.producer.KafkaWriteStream
Aborts the ongoing transaction.
addHeader(KafkaHeader) - Method in interface io.vertx.kafka.client.producer.KafkaProducerRecord
Add an header to this record.
addHeader(String, Buffer) - Method in interface io.vertx.kafka.client.producer.KafkaProducerRecord
Like KafkaProducerRecord.addHeader(KafkaHeader) but with a key/value pair
addHeader(String, String) - Method in interface io.vertx.kafka.client.producer.KafkaProducerRecord
Like KafkaProducerRecord.addHeader(KafkaHeader) but with a key/value pair
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>) - Method in interface io.vertx.kafka.admin.KafkaAdminClient
Update the configuration for the specified resources with the default options
alterConsumerGroupOffsets(String, Map<TopicPartition, OffsetAndMetadata>) - Method in interface io.vertx.kafka.admin.KafkaAdminClient
Alter committed offsets for a set of partitions in a consumer group.
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(Set<TopicPartition>) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
Manually assign a set of partitions to this consumer.
assignment() - 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.KafkaReadStream
Get the set of partitions currently assigned to this consumer.
asStream() - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
 
asStream() - Method in interface io.vertx.kafka.client.producer.KafkaProducer
 

B

batchHandler(Handler<KafkaConsumerRecords<K, V>>) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
Set the handler to be used when batches of messages are fetched from the Kafka server.
batchHandler(Handler<ConsumerRecords<K, V>>) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
Set the handler that will be called when a new batch of records is returned from Kafka.
beginningOffsets(TopicPartition) - 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
Get the first offset for the given partitions.
beginningOffsets(Set<TopicPartition>) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
Get the first offset for the given partitions.
beginningOffsets(TopicPartition) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
Get the first offset for the given partition.
beginTransaction() - Method in interface io.vertx.kafka.client.producer.KafkaProducer
Starts a new kafka transaction.
beginTransaction() - Method in interface io.vertx.kafka.client.producer.KafkaWriteStream
Starts a new kafka transaction.
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
 
BUS_DESTINATION - io.vertx.kafka.client.common.tracing.TraceTags
 

C

close() - Method in interface io.vertx.kafka.admin.KafkaAdminClient
Close the admin client
close() - 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() - 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() - 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
 
close(long) - Method in interface io.vertx.kafka.admin.KafkaAdminClient
Close the admin client
close(long) - Method in interface io.vertx.kafka.client.producer.KafkaProducer
Close the producer
close(long) - Method in interface io.vertx.kafka.client.producer.KafkaWriteStream
Close the stream
ClusterDescription - Class in io.vertx.kafka.admin
A detailed description of the cluster
ClusterDescription() - Constructor for class io.vertx.kafka.admin.ClusterDescription
Constructor
ClusterDescription(JsonObject) - Constructor for class io.vertx.kafka.admin.ClusterDescription
Constructor (from JSON representation)
ClusterDescription(String, Node, List<Node>, Set<AclOperation>) - Constructor for class io.vertx.kafka.admin.ClusterDescription
Constructor
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() - 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.KafkaConsumer
Commit the specified offsets for the specified list of topics and partitions to Kafka.
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.
committed(TopicPartition) - 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.KafkaReadStream
Get the last committed offset for the given partition (whether the commit happened by this process or another).
commitTransaction() - Method in interface io.vertx.kafka.client.producer.KafkaProducer
Commits the ongoing transaction.
commitTransaction() - Method in interface io.vertx.kafka.client.producer.KafkaWriteStream
Commits the ongoing transaction.
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(JsonObject) - Constructor for class io.vertx.kafka.admin.Config
Constructor (from JSON representation)
Config(List<ConfigEntry>) - Constructor for class io.vertx.kafka.admin.Config
Constructor
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(JsonObject) - Constructor for class io.vertx.kafka.admin.ConfigEntry
Constructor (from JSON representation)
ConfigEntry(String, String) - Constructor for class io.vertx.kafka.admin.ConfigEntry
Constructor
ConfigEntry(String, String, ConfigEntry.ConfigSource, boolean, boolean, List<ConfigSynonym>) - Constructor for class io.vertx.kafka.admin.ConfigEntry
Constructor
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(JsonObject) - Constructor for class io.vertx.kafka.client.common.ConfigResource
Constructor (from JSON representation)
ConfigResource(ConfigResource.Type, String) - Constructor for class io.vertx.kafka.client.common.ConfigResource
Constructor
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(JsonObject) - Constructor for class io.vertx.kafka.admin.ConfigSynonym
Constructor (from JSON representation)
ConfigSynonym(String, String, ConfigEntry.ConfigSource) - Constructor for class io.vertx.kafka.admin.ConfigSynonym
Constructor
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(JsonObject) - Constructor for class io.vertx.kafka.admin.ConsumerGroupDescription
Constructor (from JSON representation)
ConsumerGroupDescription(String, boolean, List<MemberDescription>, String, ConsumerGroupState, Node, Set<AclOperation>) - Constructor for class io.vertx.kafka.admin.ConsumerGroupDescription
Constructor
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(JsonObject) - Constructor for class io.vertx.kafka.admin.ConsumerGroupListing
Constructor (from JSON representation)
ConsumerGroupListing(String, boolean) - Constructor for class io.vertx.kafka.admin.ConsumerGroupListing
Constructor
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(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, KafkaClientOptions) - 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.KafkaReadStream
Create a new KafkaReadStream 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.consumer.KafkaConsumer
Create a new KafkaConsumer 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, Class<K>, Class<V>) - Static method in interface io.vertx.kafka.client.producer.KafkaWriteStream
Create a new KafkaWriteStream 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, KafkaClientOptions, Deserializer<K>, Deserializer<V>) - Static method in interface io.vertx.kafka.client.consumer.KafkaReadStream
Create a new KafkaReadStream 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, Map<String, Object>) - 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.producer.KafkaWriteStream
Create a new KafkaWriteStream 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>, Class<K>, Class<V>) - Static method in interface io.vertx.kafka.client.producer.KafkaWriteStream
Create a new KafkaWriteStream 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, Map<String, Object>, Serializer<K>, Serializer<V>) - Static method in interface io.vertx.kafka.client.producer.KafkaWriteStream
Create a new KafkaWriteStream instance
create(Vertx, Map<String, String>) - 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.client.consumer.KafkaConsumer
Create a new KafkaConsumer instance
create(Vertx, Map<String, String>) - Static method in interface io.vertx.kafka.client.producer.KafkaProducer
Create a new KafkaProducer instance
create(Vertx, Map<String, String>, Class<K>, Class<V>) - Static method in interface io.vertx.kafka.client.consumer.KafkaConsumer
Create a new KafkaConsumer 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, Map<String, String>, Deserializer<K>, Deserializer<V>) - Static method in interface io.vertx.kafka.client.consumer.KafkaConsumer
Create a new KafkaConsumer 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, Properties) - Static method in interface io.vertx.kafka.admin.KafkaAdminClient
Create a new KafkaAdminClient instance
create(Vertx, Properties) - 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) - 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.KafkaWriteStream
Create a new KafkaWriteStream 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, Class<K>, Class<V>) - 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.producer.KafkaProducer
Create a new KafkaProducer 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, Deserializer<K>, Deserializer<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.KafkaReadStream
Create a new KafkaReadStream 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, Serializer<K>, Serializer<V>) - Static method in interface io.vertx.kafka.client.producer.KafkaWriteStream
Create a new KafkaWriteStream instance
create(Vertx, AdminClient) - Static method in interface io.vertx.kafka.admin.KafkaAdminClient
Create a new KafkaAdminClient instance
create(Vertx, Consumer<K, V>) - Static method in interface io.vertx.kafka.client.consumer.KafkaConsumer
Create a new KafkaConsumer instance from a native Consumer.
create(Vertx, Consumer<K, V>) - Static method in interface io.vertx.kafka.client.consumer.KafkaReadStream
Create a new KafkaReadStream instance
create(Vertx, Consumer<K, V>, KafkaClientOptions) - Static method in interface io.vertx.kafka.client.consumer.KafkaConsumer
Create a new KafkaConsumer instance from a native Consumer.
create(Vertx, Consumer<K, V>, KafkaClientOptions) - 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, Producer<K, V>) - Static method in interface io.vertx.kafka.client.producer.KafkaWriteStream
Create a new KafkaWriteStream instance
create(Vertx, Producer<K, V>, KafkaClientOptions) - Static method in interface io.vertx.kafka.client.producer.KafkaProducer
Create a new KafkaProducer instance from a native Producer.
create(Vertx, Producer<K, V>, KafkaClientOptions) - Static method in interface io.vertx.kafka.client.producer.KafkaWriteStream
Create a new KafkaWriteStream instance.
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, 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, Long, Integer) - 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
createAcls(List<AclBinding>) - Method in interface io.vertx.kafka.admin.KafkaAdminClient
Create the ACL rules.
createPartitions(Map<String, NewPartitions>) - Method in interface io.vertx.kafka.admin.KafkaAdminClient
Creates a batch of new partitions in the Kafka topic
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, 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
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, Map<String, String>) - Static method in interface io.vertx.kafka.client.producer.KafkaProducer
Get or create a KafkaProducer instance which shares its stream with any other KafkaProducer created with the same name
createShared(Vertx, String, Map<String, String>, Class<K>, Class<V>) - Static method in interface io.vertx.kafka.client.producer.KafkaProducer
Get or create a KafkaProducer instance which shares its stream with any other KafkaProducer created with the same name
createShared(Vertx, String, 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, 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, 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, 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
createTopics(List<NewTopic>) - Method in interface io.vertx.kafka.admin.KafkaAdminClient
Creates a batch of new Kafka topics

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'
deleteAcls(List<AclBindingFilter>) - Method in interface io.vertx.kafka.admin.KafkaAdminClient
Delete the ACL rules.
deleteConsumerGroupOffsets(String, Set<TopicPartition>) - Method in interface io.vertx.kafka.admin.KafkaAdminClient
Delete committed offsets for a set of partitions in a consumer group.
deleteConsumerGroups(List<String>) - Method in interface io.vertx.kafka.admin.KafkaAdminClient
Delete consumer groups from the cluster.
deleteRecords(Map<TopicPartition, RecordsToDelete>) - Method in interface io.vertx.kafka.admin.KafkaAdminClient
Delete records from a topic partition.
deleteTopics(List<String>) - Method in interface io.vertx.kafka.admin.KafkaAdminClient
Deletes a batch of Kafka topics
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.
describeAcls(AclBindingFilter) - Method in interface io.vertx.kafka.admin.KafkaAdminClient
Describe the ACL rules.
describeCluster() - Method in interface io.vertx.kafka.admin.KafkaAdminClient
Describe the nodes in the cluster with the default options
describeCluster(DescribeClusterOptions) - Method in interface io.vertx.kafka.admin.KafkaAdminClient
Like KafkaAdminClient.describeCluster() but allows customized options.
DescribeClusterOptions - Class in io.vertx.kafka.admin
 
DescribeClusterOptions() - Constructor for class io.vertx.kafka.admin.DescribeClusterOptions
Constructor
DescribeClusterOptions(JsonObject) - Constructor for class io.vertx.kafka.admin.DescribeClusterOptions
Constructor (from JSON representation)
DescribeClusterOptionsConverter - Class in io.vertx.kafka.admin
Converter and mapper for DescribeClusterOptions.
DescribeClusterOptionsConverter() - Constructor for class io.vertx.kafka.admin.DescribeClusterOptionsConverter
 
describeConfigs(List<ConfigResource>) - Method in interface io.vertx.kafka.admin.KafkaAdminClient
Get the configuration for the specified resources with the default options
describeConsumerGroups(List<String>) - Method in interface io.vertx.kafka.admin.KafkaAdminClient
Describe some group ids in the cluster, with the default options
describeConsumerGroups(List<String>, DescribeConsumerGroupsOptions) - Method in interface io.vertx.kafka.admin.KafkaAdminClient
Like KafkaAdminClient.describeConsumerGroups(List) but allows customized options
DescribeConsumerGroupsOptions - Class in io.vertx.kafka.admin
 
DescribeConsumerGroupsOptions() - Constructor for class io.vertx.kafka.admin.DescribeConsumerGroupsOptions
Constructor
DescribeConsumerGroupsOptions(JsonObject) - Constructor for class io.vertx.kafka.admin.DescribeConsumerGroupsOptions
Constructor (from JSON representation)
DescribeConsumerGroupsOptionsConverter - Class in io.vertx.kafka.admin
Converter and mapper for DescribeConsumerGroupsOptions.
DescribeConsumerGroupsOptionsConverter() - Constructor for class io.vertx.kafka.admin.DescribeConsumerGroupsOptionsConverter
 
describeLogDirs(List<Integer>) - Method in interface io.vertx.kafka.admin.KafkaAdminClient
Query the information of all log directories on the given set of brokers
describeTopics(List<String>) - Method in interface io.vertx.kafka.admin.KafkaAdminClient
Describe some topics in the cluster, with the default options.
describeTopics(List<String>, DescribeTopicsOptions) - Method in interface io.vertx.kafka.admin.KafkaAdminClient
Like KafkaAdminClient.describeTopics(List) but allows for customised otions
DescribeTopicsOptions - Class in io.vertx.kafka.admin
 
DescribeTopicsOptions() - Constructor for class io.vertx.kafka.admin.DescribeTopicsOptions
Constructor
DescribeTopicsOptions(JsonObject) - Constructor for class io.vertx.kafka.admin.DescribeTopicsOptions
Constructor (from JSON representation)
DescribeTopicsOptionsConverter - Class in io.vertx.kafka.admin
Converter and mapper for DescribeTopicsOptions.
DescribeTopicsOptionsConverter() - Constructor for class io.vertx.kafka.admin.DescribeTopicsOptionsConverter
 
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.KafkaWriteStream
 
drainHandler(Handler<Void>) - Method in interface io.vertx.kafka.client.producer.KafkaProducer
 

E

EARLIEST - Static variable in class io.vertx.kafka.admin.OffsetSpec
 
endHandler(Handler<Void>) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
 
endHandler(Handler<Void>) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
 
endOffsets(TopicPartition) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
Get the last offset for the given partition.
endOffsets(Set<TopicPartition>) - 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.KafkaReadStream
Get the last offset for the given partitions.
endOffsets(TopicPartition) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
Get the last offset for the given partition.
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() - 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.KafkaWriteStream
Invoking this method makes all buffered records immediately available to write
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
 
getAuthorizedOperations() - Method in class io.vertx.kafka.admin.ClusterDescription
 
getAuthorizedOperations() - Method in class io.vertx.kafka.admin.ConsumerGroupDescription
 
getAuthorizedOperations() - Method in class io.vertx.kafka.admin.TopicDescription
 
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
 
getNewAssignments() - Method in class io.vertx.kafka.admin.NewPartitions
 
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
 
getTopicId() - Method in class io.vertx.kafka.admin.TopicDescription
 
getTopicPartitions() - Method in class io.vertx.kafka.admin.MemberAssignment
 
getTotalCount() - Method in class io.vertx.kafka.admin.NewPartitions
 
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<ConsumerRecord<K, V>>) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
 
handler(Handler<KafkaConsumerRecord<K, V>>) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
 
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, byte[]) - Static method in interface io.vertx.kafka.client.producer.KafkaHeader
 
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
 
headers() - Method in interface io.vertx.kafka.client.consumer.KafkaConsumerRecord
 
headers() - Method in interface io.vertx.kafka.client.producer.KafkaProducerRecord
 

I

includeAuthorizedOperations() - Method in class io.vertx.kafka.admin.DescribeClusterOptions
Specify if authorized operations should be included in the response.
includeAuthorizedOperations() - Method in class io.vertx.kafka.admin.DescribeConsumerGroupsOptions
 
includeAuthorizedOperations() - Method in class io.vertx.kafka.admin.DescribeTopicsOptions
 
includeAuthorizedOperations(boolean) - Method in class io.vertx.kafka.admin.DescribeClusterOptions
 
includeAuthorizedOperations(boolean) - Method in class io.vertx.kafka.admin.DescribeConsumerGroupsOptions
 
includeAuthorizedOperations(boolean) - Method in class io.vertx.kafka.admin.DescribeTopicsOptions
 
initTransactions() - Method in interface io.vertx.kafka.client.producer.KafkaProducer
Initializes the underlying kafka transactional producer.
initTransactions() - Method in interface io.vertx.kafka.client.producer.KafkaWriteStream
Initializes the underlying kafka transactional producer.
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) - 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
List the consumer group offsets available in the cluster.
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() - Method in interface io.vertx.kafka.admin.KafkaAdminClient
Get the the consumer groups available in the cluster with the default options
listOffsets(Map<TopicPartition, OffsetSpec>) - Method in interface io.vertx.kafka.admin.KafkaAdminClient
List the offsets available for a set of partitions.
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() - 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.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.KafkaReadStream
Get metadata about partitions for all topics that the user is authorized to view.

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(JsonObject) - Constructor for class io.vertx.kafka.admin.MemberAssignment
Constructor (from JSON representation)
MemberAssignment(Set<TopicPartition>) - Constructor for class io.vertx.kafka.admin.MemberAssignment
Constructor
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(JsonObject) - Constructor for class io.vertx.kafka.admin.MemberDescription
Constructor (from JSON representation)
MemberDescription(String, String, String, MemberAssignment) - Constructor for class io.vertx.kafka.admin.MemberDescription
Constructor
MemberDescriptionConverter - Class in io.vertx.kafka.admin
Converter and mapper for MemberDescription.
MemberDescriptionConverter() - Constructor for class io.vertx.kafka.admin.MemberDescriptionConverter
 

N

NewPartitions - Class in io.vertx.kafka.admin
An update to the number of partitions including assignment.
NewPartitions() - Constructor for class io.vertx.kafka.admin.NewPartitions
Constructor
NewPartitions(int, List<List<Integer>>) - Constructor for class io.vertx.kafka.admin.NewPartitions
Constructor
NewPartitions(JsonObject) - Constructor for class io.vertx.kafka.admin.NewPartitions
Constructor (from JSON representation)
NewPartitions(int) - Method in class io.vertx.kafka.admin.NewPartitions
Constructor
NewPartitionsConverter - Class in io.vertx.kafka.admin
Converter and mapper for NewPartitions.
NewPartitionsConverter() - Constructor for class io.vertx.kafka.admin.NewPartitionsConverter
 
NewTopic - Class in io.vertx.kafka.admin
A new topic to be created
NewTopic() - Constructor for class io.vertx.kafka.admin.NewTopic
Constructor
NewTopic(JsonObject) - Constructor for class io.vertx.kafka.admin.NewTopic
Constructor (from JSON representation)
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
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(TopicPartition, Long) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
Look up the offset for the given partition by timestamp.
offsetsForTimes(Map<TopicPartition, Long>) - 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.KafkaReadStream
Look up the offsets for the given partitions by timestamp.
offsetsForTimes(TopicPartition, long) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
* Look up the offset for the given partition by timestamp.
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(JsonObject) - Constructor for class io.vertx.kafka.client.common.PartitionInfo
Constructor (from JSON representation)
PartitionInfo(List<Node>, Node, int, List<Node>, String) - Constructor for class io.vertx.kafka.client.common.PartitionInfo
Constructor
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) - 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.KafkaReadStream
Get metadata about the partitions for a given topic.
partitionsFor(String) - 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.KafkaWriteStream
Get the partition metadata for the give topic.
partitionsRevokedHandler(Handler<Set<TopicPartition>>) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
Set the handler called when topic partitions are revoked to the consumer
partitionsRevokedHandler(Handler<Set<TopicPartition>>) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
Set the handler called when topic partitions are revoked to the consumer
pause() - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
 
pause() - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
 
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(Set<TopicPartition>) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
Suspend fetching from the requested partitions.
paused() - 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.KafkaReadStream
Get the set of partitions that were previously paused by a call to KafkaReadStream.pause(Set).
PEER_SERVICE - io.vertx.kafka.client.common.tracing.TraceTags
 
poll(Duration) - 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.KafkaReadStream
Executes a poll for getting messages from Kafka.
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) - 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.KafkaReadStream
Get the offset of the next record that will be fetched (if a record with that offset exists).
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, 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() - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
 
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(Set<TopicPartition>) - 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, OffsetAndMetadata) - 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, OffsetAndMetadata) - 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(Set<TopicPartition>) - 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(Set<TopicPartition>) - 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(ProducerRecord<K, V>) - 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
 
SERVER_ADDRESS - io.vertx.kafka.client.common.tracing.TraceTags
 
SERVER_PORT - io.vertx.kafka.client.common.tracing.TraceTags
 
setAssignment(MemberAssignment) - Method in class io.vertx.kafka.admin.MemberDescription
Set the assignment of the group member
setAuthorizedOperations(Set<AclOperation>) - Method in class io.vertx.kafka.admin.ClusterDescription
Set the authorizedOperations
setAuthorizedOperations(Set<AclOperation>) - Method in class io.vertx.kafka.admin.ConsumerGroupDescription
Set the id of the consumer group
setAuthorizedOperations(Set<AclOperation>) - Method in class io.vertx.kafka.admin.TopicDescription
Set the id of the consumer group
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(String, Object) - Method in class io.vertx.kafka.client.common.KafkaClientOptions
Set a Kafka config entry.
setConfig(Map<String, Object>) - Method in class io.vertx.kafka.client.common.KafkaClientOptions
Set the Kafka config.
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
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
setNewAssignments(List<List<Integer>>) - Method in class io.vertx.kafka.admin.NewPartitions
Set the assignment for the new partitions
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
setTopicId(Uuid) - Method in class io.vertx.kafka.admin.TopicDescription
Set the id of the topic.
setTopicPartitions(Set<TopicPartition>) - Method in class io.vertx.kafka.admin.MemberAssignment
Set the list of topic partitions
setTotalCount(int) - Method in class io.vertx.kafka.admin.NewPartitions
Set the number of partitions for the topic
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(Pattern) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
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.
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(Set<String>) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
Subscribe to the given list of topics to get dynamically assigned partitions.
subscription() - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
Get the current subscription.
subscription() - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
Get the current subscription.

T

timestamp() - Method in interface io.vertx.kafka.client.consumer.KafkaConsumerRecord
 
timestamp() - Method in interface io.vertx.kafka.client.producer.KafkaProducerRecord
 
TIMESTAMP(long) - Static method in class io.vertx.kafka.admin.OffsetSpec
 
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() - Method in class io.vertx.kafka.admin.Config
Convert object to JSON representation
toJson() - Method in class io.vertx.kafka.admin.ConfigEntry
Convert object to JSON representation
toJson() - Method in class io.vertx.kafka.admin.ConfigSynonym
Convert object to JSON representation
toJson() - Method in class io.vertx.kafka.admin.ConsumerGroupDescription
Convert object to JSON representation
toJson() - Method in class io.vertx.kafka.admin.ConsumerGroupListing
Convert object to JSON representation
toJson() - Method in class io.vertx.kafka.admin.DescribeClusterOptions
Convert object to JSON representation
toJson() - Method in class io.vertx.kafka.admin.DescribeConsumerGroupsOptions
Convert object to JSON representation
toJson() - Method in class io.vertx.kafka.admin.DescribeTopicsOptions
Convert object to JSON representation
toJson() - Method in class io.vertx.kafka.admin.ListConsumerGroupOffsetsOptions
Convert object to JSON representation
toJson() - Method in class io.vertx.kafka.admin.ListOffsetsResultInfo
Convert object to JSON representation
toJson() - Method in class io.vertx.kafka.admin.MemberAssignment
Convert object to JSON representation
toJson() - Method in class io.vertx.kafka.admin.MemberDescription
Convert object to JSON representation
toJson() - Method in class io.vertx.kafka.admin.NewPartitions
Convert object to JSON representation
toJson() - Method in class io.vertx.kafka.admin.NewTopic
Convert object to JSON representation
toJson() - Method in class io.vertx.kafka.admin.OffsetSpec
Convert object to JSON representation
toJson() - Method in class io.vertx.kafka.admin.TopicDescription
Convert object to JSON representation
toJson() - Method in class io.vertx.kafka.client.common.ConfigResource
Convert object to JSON representation
toJson() - Method in class io.vertx.kafka.client.common.KafkaClientOptions
 
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() - 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() - 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>, Uuid, Set<AclOperation>) - 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(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)
TopicPartition(String, int) - Constructor for class io.vertx.kafka.client.common.TopicPartition
Constructor
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(JsonObject) - Constructor for class io.vertx.kafka.client.common.TopicPartitionInfo
Constructor (from JSON representation)
TopicPartitionInfo(List<Node>, Node, int, List<Node>) - Constructor for class io.vertx.kafka.client.common.TopicPartitionInfo
Constructor
TopicPartitionInfoConverter - Class in io.vertx.kafka.client.common
Converter and mapper for TopicPartitionInfo.
TopicPartitionInfoConverter() - Constructor for class io.vertx.kafka.client.common.TopicPartitionInfoConverter
 
topicPartitions() - Method in class io.vertx.kafka.admin.ListConsumerGroupOffsetsOptions
Returns a list of topic partitions to add as part of the result.
topicPartitions(List<TopicPartition>) - Method in class io.vertx.kafka.admin.ListConsumerGroupOffsetsOptions
Set the topic partitions to list 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.DescribeClusterOptions
 
toString() - Method in class io.vertx.kafka.admin.DescribeConsumerGroupsOptions
 
toString() - Method in class io.vertx.kafka.admin.DescribeTopicsOptions
 
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.NewPartitions
 
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() - 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 
All Classes All Packages