- changeTopicConfig(String, Map<String, String>, Handler<AsyncResult<Void>>) - Method in interface io.vertx.kafka.admin.AdminUtils
-
Updates the configuration of the topic given by topicName.
- checksum() - Method in interface io.vertx.kafka.client.consumer.KafkaConsumerRecord
-
- checksum() - Method in class io.vertx.kafka.client.producer.RecordMetadata
-
- close(Handler<AsyncResult<Void>>) - Method in interface io.vertx.kafka.admin.AdminUtils
-
Closes the underlying connection to Zookeeper.
- close() - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
-
Close the consumer
- close(Handler<AsyncResult<Void>>) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
-
Close the consumer
- close() - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
-
Close the stream
- close(Handler<AsyncResult<Void>>) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
-
Close the stream
- close() - Method in interface io.vertx.kafka.client.producer.KafkaProducer
-
Close the producer
- close(Handler<AsyncResult<Void>>) - Method in interface io.vertx.kafka.client.producer.KafkaProducer
-
Close the producer
- close(long, Handler<AsyncResult<Void>>) - Method in interface io.vertx.kafka.client.producer.KafkaProducer
-
Close the producer
- close() - Method in interface io.vertx.kafka.client.producer.KafkaWriteStream
-
Close the stream
- close(Handler<AsyncResult<Void>>) - Method in interface io.vertx.kafka.client.producer.KafkaWriteStream
-
Close the stream
- close(long, Handler<AsyncResult<Void>>) - Method in interface io.vertx.kafka.client.producer.KafkaWriteStream
-
Close the stream
- close() - Method in class io.vertx.kafka.client.serialization.BufferDeserializer
-
- close() - Method in class io.vertx.kafka.client.serialization.BufferSerializer
-
- close() - Method in class io.vertx.kafka.client.serialization.JsonArrayDeserializer
-
- close() - Method in class io.vertx.kafka.client.serialization.JsonArraySerializer
-
- close() - Method in class io.vertx.kafka.client.serialization.JsonObjectDeserializer
-
- close() - Method in class io.vertx.kafka.client.serialization.JsonObjectSerializer
-
- commit() - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
-
Commit current offsets for all the subscribed list of topics and partition.
- commit(Handler<AsyncResult<Void>>) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
-
Commit current offsets for all the subscribed list of topics and partition.
- commit(Map<TopicPartition, OffsetAndMetadata>) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
-
Commit the specified offsets for the specified list of topics and partitions to Kafka.
- commit(Map<TopicPartition, OffsetAndMetadata>, Handler<AsyncResult<Map<TopicPartition, OffsetAndMetadata>>>) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
-
Commit the specified offsets for the specified list of topics and partitions to Kafka.
- commit() - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
-
Commit current offsets for all the subscribed list of topics and partition.
- commit(Handler<AsyncResult<Map<TopicPartition, OffsetAndMetadata>>>) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
-
Commit current offsets for all the subscribed list of topics and partition.
- commit(Map<TopicPartition, OffsetAndMetadata>) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
-
Commit the specified offsets for the specified list of topics and partitions to Kafka.
- commit(Map<TopicPartition, OffsetAndMetadata>, Handler<AsyncResult<Map<TopicPartition, OffsetAndMetadata>>>) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
-
Commit the specified offsets for the specified list of topics and partitions to Kafka.
- committed(TopicPartition, Handler<AsyncResult<OffsetAndMetadata>>) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
-
Get the last committed offset for the given partition (whether the commit happened by this process or another).
- committed(TopicPartition, Handler<AsyncResult<OffsetAndMetadata>>) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
-
Get the last committed offset for the given partition (whether the commit happened by this process or another).
- configure(Map<String, ?>, boolean) - Method in class io.vertx.kafka.client.serialization.BufferDeserializer
-
- configure(Map<String, ?>, boolean) - Method in class io.vertx.kafka.client.serialization.BufferSerializer
-
- configure(Map<String, ?>, boolean) - Method in class io.vertx.kafka.client.serialization.JsonArrayDeserializer
-
- configure(Map<String, ?>, boolean) - Method in class io.vertx.kafka.client.serialization.JsonArraySerializer
-
- configure(Map<String, ?>, boolean) - Method in class io.vertx.kafka.client.serialization.JsonObjectDeserializer
-
- configure(Map<String, ?>, boolean) - Method in class io.vertx.kafka.client.serialization.JsonObjectSerializer
-
- create(Vertx, String) - Static method in interface io.vertx.kafka.admin.AdminUtils
-
Create a new AdminUtils instance
- create(Vertx, String, boolean) - Static method in interface io.vertx.kafka.admin.AdminUtils
-
Create a new AdminUtils instance
- create(Vertx, String, int, boolean, boolean) - Static method in interface io.vertx.kafka.admin.AdminUtils
-
Create a new AdminUtils instance
- create(Vertx, Consumer<K, V>) - Static method in interface io.vertx.kafka.client.consumer.KafkaConsumer
-
Create a new KafkaConsumer instance from a native Consumer
.
- create(Vertx, Map<String, String>) - Static method in interface io.vertx.kafka.client.consumer.KafkaConsumer
-
Create a new KafkaConsumer instance
- create(Vertx, Map<String, String>, Class<K>, Class<V>) - Static method in interface io.vertx.kafka.client.consumer.KafkaConsumer
-
Create a new KafkaConsumer instance
- create(Vertx, Properties) - Static method in interface io.vertx.kafka.client.consumer.KafkaConsumer
-
Create a new KafkaConsumer instance
- create(Vertx, Properties, Class<K>, Class<V>) - Static method in interface io.vertx.kafka.client.consumer.KafkaConsumer
-
Create a new KafkaConsumer instance
- create(Vertx, Properties) - Static method in interface io.vertx.kafka.client.consumer.KafkaReadStream
-
Create a new KafkaReadStream instance
- create(Vertx, Properties, Class<K>, Class<V>) - Static method in interface io.vertx.kafka.client.consumer.KafkaReadStream
-
Create a new KafkaReadStream instance
- create(Vertx, Map<String, Object>) - Static method in interface io.vertx.kafka.client.consumer.KafkaReadStream
-
Create a new KafkaReadStream instance
- create(Vertx, Map<String, Object>, Class<K>, Class<V>) - Static method in interface io.vertx.kafka.client.consumer.KafkaReadStream
-
Create a new KafkaReadStream instance
- create(Vertx, Consumer<K, V>) - Static method in interface io.vertx.kafka.client.consumer.KafkaReadStream
-
Create a new KafkaReadStream instance
- create(Vertx, Producer<K, V>) - Static method in interface io.vertx.kafka.client.producer.KafkaProducer
-
Create a new KafkaProducer instance from a native Producer
.
- create(Vertx, Map<String, String>) - Static method in interface io.vertx.kafka.client.producer.KafkaProducer
-
Create a new KafkaProducer instance
- create(Vertx, Map<String, String>, Class<K>, Class<V>) - Static method in interface io.vertx.kafka.client.producer.KafkaProducer
-
Create a new KafkaProducer instance
- create(Vertx, Properties) - Static method in interface io.vertx.kafka.client.producer.KafkaProducer
-
Create a new KafkaProducer instance
- create(Vertx, Properties, Class<K>, Class<V>) - Static method in interface io.vertx.kafka.client.producer.KafkaProducer
-
Create a new KafkaProducer instance
- create(String, K, V, Long, Integer) - Static method in interface io.vertx.kafka.client.producer.KafkaProducerRecord
-
Create a concrete instance of a Vert.x producer record
- create(String, K, V, Integer) - Static method in interface io.vertx.kafka.client.producer.KafkaProducerRecord
-
Create a concrete instance of a Vert.x producer record
- create(String, K, V) - Static method in interface io.vertx.kafka.client.producer.KafkaProducerRecord
-
Create a concrete instance of a Vert.x producer record
- create(String, V) - Static method in interface io.vertx.kafka.client.producer.KafkaProducerRecord
-
Create a concrete instance of a Vert.x producer record
- create(Vertx, Properties) - Static method in interface io.vertx.kafka.client.producer.KafkaWriteStream
-
Create a new KafkaWriteStream instance
- create(Vertx, Properties, Class<K>, Class<V>) - Static method in interface io.vertx.kafka.client.producer.KafkaWriteStream
-
Create a new KafkaWriteStream instance
- create(Vertx, Map<String, Object>) - Static method in interface io.vertx.kafka.client.producer.KafkaWriteStream
-
Create a new KafkaWriteStream instance
- create(Vertx, Map<String, Object>, Class<K>, Class<V>) - Static method in interface io.vertx.kafka.client.producer.KafkaWriteStream
-
Create a new KafkaWriteStream instance
- create(Vertx, Producer<K, V>) - Static method in interface io.vertx.kafka.client.producer.KafkaWriteStream
-
Create a new KafkaWriteStream instance
- createShared(Vertx, String, Properties) - Static method in interface io.vertx.kafka.client.producer.KafkaProducer
-
Get or create a KafkaProducer instance which shares its stream with any other KafkaProducer created with the same name
- createShared(Vertx, String, Map<String, String>) - Static method in interface io.vertx.kafka.client.producer.KafkaProducer
-
Get or create a KafkaProducer instance which shares its stream with any other KafkaProducer created with the same name
- createShared(Vertx, String, Map<String, String>, Class<K>, Class<V>) - Static method in interface io.vertx.kafka.client.producer.KafkaProducer
-
Get or create a KafkaProducer instance which shares its stream with any other KafkaProducer created with the same name
- createShared(Vertx, String, Properties, Class<K>, Class<V>) - Static method in interface io.vertx.kafka.client.producer.KafkaProducer
-
Get or create a KafkaProducer instance which shares its stream with any other KafkaProducer created with the same name
- createTopic(String, int, int, Handler<AsyncResult<Void>>) - Method in interface io.vertx.kafka.admin.AdminUtils
-
Creates a new Kafka topic on all Brokers managed by the given Zookeeper instance(s)
- createTopic(String, int, int, Map<String, String>, Handler<AsyncResult<Void>>) - Method in interface io.vertx.kafka.admin.AdminUtils
-
Creates a new Kafka topic on all Brokers managed by the given Zookeeper instance(s).
- 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, Handler<AsyncResult<List<PartitionInfo>>>) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
-
Get metadata about the partitions for a given topic.
- partitionsFor(String, Handler<AsyncResult<List<PartitionInfo>>>) - Method in interface io.vertx.kafka.client.producer.KafkaProducer
-
Get the partition metadata for the give topic.
- partitionsFor(String, Handler<AsyncResult<List<PartitionInfo>>>) - Method in interface io.vertx.kafka.client.producer.KafkaWriteStream
-
Get the partition metadata for the give topic.
- partitionsRevokedHandler(Handler<Set<TopicPartition>>) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
-
Set the handler called when topic partitions are revoked to the consumer
- partitionsRevokedHandler(Handler<Set<TopicPartition>>) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
-
Set the handler called when topic partitions are revoked to the consumer
- pause() - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
-
- pause(TopicPartition) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
-
Suspend fetching from the requested partition.
- pause(Set<TopicPartition>) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
-
Suspend fetching from the requested partitions.
- pause(TopicPartition, Handler<AsyncResult<Void>>) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
-
Suspend fetching from the requested partition.
- pause(Set<TopicPartition>, Handler<AsyncResult<Void>>) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
-
Suspend fetching from the requested partitions.
- pause(Set<TopicPartition>) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
-
Suspend fetching from the requested partitions.
- pause(Set<TopicPartition>, Handler<AsyncResult<Void>>) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
-
Suspend fetching from the requested partitions.
- paused(Handler<AsyncResult<Set<TopicPartition>>>) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
-
Get the set of partitions that were previously paused by a call to pause(Set).
- paused(Handler<AsyncResult<Set<TopicPartition>>>) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
-
- poll(long, Handler<AsyncResult<KafkaConsumerRecords<K, V>>>) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
-
Executes a poll for getting messages from Kafka
- poll(long, Handler<AsyncResult<ConsumerRecords<K, V>>>) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
-
Executes a poll for getting messages from Kafka
- pollTimeout(long) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
-
Sets the poll timeout (in ms) for the underlying native Kafka Consumer.
- pollTimeout(long) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
-
Sets the poll timeout (in ms) for the underlying native Kafka Consumer.
- position(TopicPartition, Handler<AsyncResult<Long>>) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
-
Get the offset of the next record that will be fetched (if a record with that offset exists).
- position(TopicPartition, Handler<AsyncResult<Long>>) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
-
Get the offset of the next record that will be fetched (if a record with that offset exists).
- seek(TopicPartition, long) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
-
Overrides the fetch offsets that the consumer will use on the next poll.
- seek(TopicPartition, long, Handler<AsyncResult<Void>>) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
-
Overrides the fetch offsets that the consumer will use on the next poll.
- seek(TopicPartition, long) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
-
Overrides the fetch offsets that the consumer will use on the next poll.
- seek(TopicPartition, long, Handler<AsyncResult<Void>>) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
-
Overrides the fetch offsets that the consumer will use on the next poll.
- seekToBeginning(TopicPartition) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
-
Seek to the first offset for each of the given partition.
- seekToBeginning(Set<TopicPartition>) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
-
Seek to the first offset for each of the given partitions.
- seekToBeginning(TopicPartition, Handler<AsyncResult<Void>>) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
-
Seek to the first offset for each of the given partition.
- seekToBeginning(Set<TopicPartition>, Handler<AsyncResult<Void>>) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
-
Seek to the first offset for each of the given partitions.
- seekToBeginning(Set<TopicPartition>) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
-
Seek to the first offset for each of the given partitions.
- seekToBeginning(Set<TopicPartition>, Handler<AsyncResult<Void>>) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
-
Seek to the first offset for each of the given partitions.
- seekToEnd(TopicPartition) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
-
Seek to the last offset for each of the given partition.
- seekToEnd(Set<TopicPartition>) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
-
Seek to the last offset for each of the given partitions.
- seekToEnd(TopicPartition, Handler<AsyncResult<Void>>) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
-
Seek to the last offset for each of the given partition.
- seekToEnd(Set<TopicPartition>, Handler<AsyncResult<Void>>) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
-
Seek to the last offset for each of the given partitions.
- seekToEnd(Set<TopicPartition>) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
-
Seek to the last offset for each of the given partitions.
- seekToEnd(Set<TopicPartition>, Handler<AsyncResult<Void>>) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
-
Seek to the last offset for each of the given partitions.
- serdeFrom(Class<T>) - Static method in class io.vertx.kafka.client.serialization.VertxSerdes
-
- serialize(String, Buffer) - Method in class io.vertx.kafka.client.serialization.BufferSerializer
-
- serialize(String, JsonArray) - Method in class io.vertx.kafka.client.serialization.JsonArraySerializer
-
- serialize(String, JsonObject) - Method in class io.vertx.kafka.client.serialization.JsonObjectSerializer
-
- setChecksum(long) - Method in class io.vertx.kafka.client.producer.RecordMetadata
-
Set the checksum (CRC32) of the record.
- setHasRack(boolean) - Method in class io.vertx.kafka.client.common.Node
-
Set if this node has a defined rack
- setHost(String) - Method in class io.vertx.kafka.client.common.Node
-
Set the host name for this node
- setId(int) - Method in class io.vertx.kafka.client.common.Node
-
Set the node id of this node
- setIdString(String) - Method in class io.vertx.kafka.client.common.Node
-
Set the string representation of the node id
- setInSyncReplicas(List<Node>) - Method in class io.vertx.kafka.client.common.PartitionInfo
-
Set the subset of the replicas that are in sync
- setIsEmpty(boolean) - Method in class io.vertx.kafka.client.common.Node
-
Set if this node is empty
- setLeader(Node) - Method in class io.vertx.kafka.client.common.PartitionInfo
-
Set the node id of the node currently acting as a leader
- setMetadata(String) - Method in class io.vertx.kafka.client.consumer.OffsetAndMetadata
-
Set additional metadata for the offset committed
- setOffset(long) - Method in class io.vertx.kafka.client.consumer.OffsetAndMetadata
-
Set the offset to commit
- setOffset(long) - Method in class io.vertx.kafka.client.consumer.OffsetAndTimestamp
-
Set the offset
- setOffset(long) - Method in class io.vertx.kafka.client.producer.RecordMetadata
-
Set the offset of the record in the topic/partition.
- setPartition(int) - Method in class io.vertx.kafka.client.common.PartitionInfo
-
Set the partition id
- setPartition(int) - Method in class io.vertx.kafka.client.common.TopicPartition
-
Set the partition number
- setPartition(int) - Method in class io.vertx.kafka.client.producer.RecordMetadata
-
Set the partition the record was sent to
- setPort(int) - Method in class io.vertx.kafka.client.common.Node
-
Set the port for this node
- setRack(String) - Method in class io.vertx.kafka.client.common.Node
-
Set the rack for this node
- setReplicas(List<Node>) - Method in class io.vertx.kafka.client.common.PartitionInfo
-
Set the complete set of replicas for this partition
- setTimestamp(long) - Method in class io.vertx.kafka.client.consumer.OffsetAndTimestamp
-
Set the timestamp
- setTimestamp(long) - Method in class io.vertx.kafka.client.producer.RecordMetadata
-
Set the timestamp of the record in the topic/partition
- setTopic(String) - Method in class io.vertx.kafka.client.common.PartitionInfo
-
Set the topic name
- setTopic(String) - Method in class io.vertx.kafka.client.common.TopicPartition
-
Set the topic name
- setTopic(String) - Method in class io.vertx.kafka.client.producer.RecordMetadata
-
Set the topic the record was appended to
- setWriteQueueMaxSize(int) - Method in interface io.vertx.kafka.client.producer.KafkaProducer
-
- size() - Method in interface io.vertx.kafka.client.consumer.KafkaConsumerRecords
-
- subscribe(String) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
-
Subscribe to the given topic to get dynamically assigned partitions.
- subscribe(Set<String>) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
-
Subscribe to the given list of topics to get dynamically assigned partitions.
- subscribe(String, Handler<AsyncResult<Void>>) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
-
Subscribe to the given topic to get dynamically assigned partitions.
- subscribe(Set<String>, Handler<AsyncResult<Void>>) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
-
Subscribe to the given list of topics to get dynamically assigned partitions.
- subscribe(Set<String>) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
-
Subscribe to the given list of topics to get dynamically assigned partitions.
- subscribe(Set<String>, Handler<AsyncResult<Void>>) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
-
Subscribe to the given list of topics to get dynamically assigned partitions.
- subscription(Handler<AsyncResult<Set<String>>>) - Method in interface io.vertx.kafka.client.consumer.KafkaConsumer
-
Get the current subscription.
- subscription(Handler<AsyncResult<Set<String>>>) - Method in interface io.vertx.kafka.client.consumer.KafkaReadStream
-
Get the current subscription.