- checksum() - Method in interface io.vertx.kafka.client.consumer.KafkaConsumerRecord
-
- checksum() - Method in class io.vertx.kafka.client.producer.RecordMetadata
-
- close(Handler<AsyncResult<Void>>) - Method in interface io.vertx.kafka.admin.KafkaAdminClient
-
Close the admin client
- close() - Method in interface io.vertx.kafka.admin.KafkaAdminClient
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- paused(Handler<AsyncResult<Set<TopicPartition>>>) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
-
- paused() - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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