Index
All Classes and Interfaces|All Packages
A
- Acks - Class in io.github.eocqrs.kafka.parameters
-
It's a wrapper for the `acks` kafka attribute.
- Acks(String) - Constructor for class io.github.eocqrs.kafka.parameters.Acks
-
Ctor.
- Action - Interface in io.github.eocqrs.kafka.act
-
Kafka Action.
- all() - Method in class io.github.eocqrs.kafka.consumer.settings.KfConsumerParams
- all() - Method in class io.github.eocqrs.kafka.parameters.KfParams
- all() - Method in interface io.github.eocqrs.kafka.Params
-
Returns a collection of all the settings attributes.
- all() - Method in class io.github.eocqrs.kafka.producer.settings.KfProducerParams
- apply() - Method in interface io.github.eocqrs.kafka.act.Action
-
Apply action.
- apply() - Method in class io.github.eocqrs.kafka.act.AssignPartitions
- apply() - Method in class io.github.eocqrs.kafka.act.CommitAsync
- apply() - Method in class io.github.eocqrs.kafka.act.CommitSync
- apply() - Method in class io.github.eocqrs.kafka.act.Wakeup
- apply(Iterable<Directive>) - Method in interface io.github.eocqrs.kafka.fake.storage.FkStorage
-
Deprecated.Update XML with new directives.
- apply(Iterable<Directive>) - Method in class io.github.eocqrs.kafka.fake.storage.InFile
-
Deprecated.
- AssignPartitions - Class in io.github.eocqrs.kafka.act
-
Assign Partitions for Kafka Consumer.
- AssignPartitions(KafkaConsumer<?, ?>, Collection<TopicPartition>) - Constructor for class io.github.eocqrs.kafka.act.AssignPartitions
-
Ctor.
- AssignPartitions(KafkaConsumer<?, ?>, TopicPartition...) - Constructor for class io.github.eocqrs.kafka.act.AssignPartitions
-
Ctor.
- asXml() - Method in class io.github.eocqrs.kafka.consumer.settings.KfConsumerParams
- asXml() - Method in class io.github.eocqrs.kafka.parameters.KfAttrEnvelope
- asXml() - Method in class io.github.eocqrs.kafka.parameters.KfParams
- asXml() - Method in interface io.github.eocqrs.kafka.Params
-
Returns the XML representation of the settings.
- asXml() - Method in interface io.github.eocqrs.kafka.ParamsAttr
-
Represents settings as XML.
- asXml() - Method in class io.github.eocqrs.kafka.producer.settings.KfProducerParams
- AutoOffsetReset - Class in io.github.eocqrs.kafka.parameters
-
It's a wrapper for the `auto.offset.reset` kafka attribute.
- AutoOffsetReset(String) - Constructor for class io.github.eocqrs.kafka.parameters.AutoOffsetReset
-
Ctor.
B
- BatchSize - Class in io.github.eocqrs.kafka.parameters
-
It's a wrapper for the `batch.size` kafka attribute.
- BatchSize(String) - Constructor for class io.github.eocqrs.kafka.parameters.BatchSize
-
Ctor.
- BootstrapServers - Class in io.github.eocqrs.kafka.parameters
-
It's a wrapper for the `bootstrap.servers` kafka attribute.
- BootstrapServers(String) - Constructor for class io.github.eocqrs.kafka.parameters.BootstrapServers
-
Ctor.
- BufferMemory - Class in io.github.eocqrs.kafka.parameters
-
It's a wrapper for the `buffer.memory` kafka attribute.
- BufferMemory(String) - Constructor for class io.github.eocqrs.kafka.parameters.BufferMemory
-
Ctor.
C
- ClientId - Class in io.github.eocqrs.kafka.parameters
-
It's a wrapper for the `client.id` kafka attribute.
- ClientId(String) - Constructor for class io.github.eocqrs.kafka.parameters.ClientId
-
Ctor.
- ClientRack - Class in io.github.eocqrs.kafka.parameters
-
It's a wrapper for the `client.rack` kafka attribute.
- ClientRack(String) - Constructor for class io.github.eocqrs.kafka.parameters.ClientRack
-
Ctor.
- close() - Method in class io.github.eocqrs.kafka.consumer.KfConsumer
- close() - Method in class io.github.eocqrs.kafka.fake.FkConsumer
- close() - Method in class io.github.eocqrs.kafka.fake.FkProducer
- close() - Method in class io.github.eocqrs.kafka.producer.KfCallback
- close() - Method in class io.github.eocqrs.kafka.producer.KfProducer
- CommitAsync - Class in io.github.eocqrs.kafka.act
-
Async Offset Commit.
- CommitAsync() - Constructor for class io.github.eocqrs.kafka.act.CommitAsync
- CommitSync - Class in io.github.eocqrs.kafka.act
-
Sync Offset Commit.
- CommitSync() - Constructor for class io.github.eocqrs.kafka.act.CommitSync
- CompressionType - Class in io.github.eocqrs.kafka.parameters
-
It's a wrapper for the `compression.type` kafka attribute.
- CompressionType(String) - Constructor for class io.github.eocqrs.kafka.parameters.CompressionType
-
Ctor.
- consumer() - Method in interface io.github.eocqrs.kafka.ConsumerSettings
-
Kafka Consumer.
- consumer() - Method in class io.github.eocqrs.kafka.parameters.KfFlexible
- consumer() - Method in class io.github.eocqrs.kafka.xml.KfXmlFlexible
- Consumer<K,
X> - Interface in io.github.eocqrs.kafka -
Consumer.
- ConsumerSettings<K,
X> - Interface in io.github.eocqrs.kafka -
Consumer Settings.
D
- data(String) - Method in interface io.github.eocqrs.kafka.fake.FkBroker
-
Query data.
- data(String) - Method in class io.github.eocqrs.kafka.fake.InXml
- Data<X> - Interface in io.github.eocqrs.kafka
-
Message Data.
- dataize() - Method in class io.github.eocqrs.kafka.data.KfDataized
- dataize() - Method in interface io.github.eocqrs.kafka.Dataized
-
Dataize.
- dataized() - Method in interface io.github.eocqrs.kafka.Data
-
Dataized.
- dataized() - Method in class io.github.eocqrs.kafka.data.KfData
- Dataized<T> - Interface in io.github.eocqrs.kafka
-
Dataized.
- DeliveryTimeoutMs - Class in io.github.eocqrs.kafka.parameters
-
It's a wrapper for the `delivery.timeout.ms` kafka attribute.
- DeliveryTimeoutMs(String) - Constructor for class io.github.eocqrs.kafka.parameters.DeliveryTimeoutMs
-
Ctor.
E
- EnableAutoCommit - Class in io.github.eocqrs.kafka.parameters
-
It's a wrapper for the `enable.auto.commit` kafka attribute.
- EnableAutoCommit(String) - Constructor for class io.github.eocqrs.kafka.parameters.EnableAutoCommit
-
Ctor.
- EnableIdempotence - Class in io.github.eocqrs.kafka.parameters
-
It's a wrapper for the `enable.idempotence` kafka attribute.
- EnableIdempotence(String) - Constructor for class io.github.eocqrs.kafka.parameters.EnableIdempotence
-
Ctor.
F
- FetchMaxBytes - Class in io.github.eocqrs.kafka.parameters
-
It's a wrapper for the `fetch.max.bytes` kafka attribute.
- FetchMaxBytes(String) - Constructor for class io.github.eocqrs.kafka.parameters.FetchMaxBytes
-
Ctor.
- FetchMaxWaitMs - Class in io.github.eocqrs.kafka.parameters
-
It's a wrapper for the `fetch.max.wait.ms` kafka attribute.
- FetchMaxWaitMs(String) - Constructor for class io.github.eocqrs.kafka.parameters.FetchMaxWaitMs
-
Ctor.
- FetchMinBytes - Class in io.github.eocqrs.kafka.parameters
-
It's a wrapper for the `fetch.min.bytes` kafka attribute.
- FetchMinBytes(String) - Constructor for class io.github.eocqrs.kafka.parameters.FetchMinBytes
-
Ctor.
- FkBroker - Interface in io.github.eocqrs.kafka.fake
-
Fake Kafka Broker.
- FkConsumer<K,
X> - Class in io.github.eocqrs.kafka.fake -
Fake Consumer.
- FkConsumer() - Constructor for class io.github.eocqrs.kafka.fake.FkConsumer
- FkProducer<K,
X> - Class in io.github.eocqrs.kafka.fake -
Fake Producer.
- FkProducer() - Constructor for class io.github.eocqrs.kafka.fake.FkProducer
- FkStorage - Interface in io.github.eocqrs.kafka.fake.storage
-
Deprecated.
G
- GroupId - Class in io.github.eocqrs.kafka.parameters
-
It's a wrapper for the `group.id` kafka attribute.
- GroupId(String) - Constructor for class io.github.eocqrs.kafka.parameters.GroupId
-
Ctor.
- GroupInstanceId - Class in io.github.eocqrs.kafka.parameters
-
It's a wrapper for the `group.instance.id` kafka attribute.
- GroupInstanceId(String) - Constructor for class io.github.eocqrs.kafka.parameters.GroupInstanceId
-
Ctor.
H
- HeartbeatIntervalMs - Class in io.github.eocqrs.kafka.parameters
-
It's a wrapper for the `heartbeat.interval.ms` kafka attribute.
- HeartbeatIntervalMs(String) - Constructor for class io.github.eocqrs.kafka.parameters.HeartbeatIntervalMs
-
Ctor.
I
- InFile - Class in io.github.eocqrs.kafka.fake.storage
-
Deprecated.use
InFile - InFile() - Constructor for class io.github.eocqrs.kafka.fake.storage.InFile
-
Deprecated.Ctor.
- InFile(File) - Constructor for class io.github.eocqrs.kafka.fake.storage.InFile
-
Deprecated.Ctor.
- InXml - Class in io.github.eocqrs.kafka.fake
-
Synced Kafka Broker.
- InXml(FkStorage) - Constructor for class io.github.eocqrs.kafka.fake.InXml
-
Ctor.
- io.github.eocqrs.kafka - package io.github.eocqrs.kafka
-
Kafka API.
- io.github.eocqrs.kafka.act - package io.github.eocqrs.kafka.act
-
Kafka Actions.
- io.github.eocqrs.kafka.consumer - package io.github.eocqrs.kafka.consumer
-
Kafka API-Consumers.
- io.github.eocqrs.kafka.consumer.settings - package io.github.eocqrs.kafka.consumer.settings
-
Kafka API-ConsumerSettings.
- io.github.eocqrs.kafka.data - package io.github.eocqrs.kafka.data
-
Kafka API-Data.
- io.github.eocqrs.kafka.fake - package io.github.eocqrs.kafka.fake
-
Fake.
- io.github.eocqrs.kafka.fake.storage - package io.github.eocqrs.kafka.fake.storage
- io.github.eocqrs.kafka.parameters - package io.github.eocqrs.kafka.parameters
-
Kafka Parameters.
- io.github.eocqrs.kafka.producer - package io.github.eocqrs.kafka.producer
-
Kafka API-Producers.
- io.github.eocqrs.kafka.producer.settings - package io.github.eocqrs.kafka.producer.settings
-
Kafka API-ProducerSettings.
- io.github.eocqrs.kafka.xml - package io.github.eocqrs.kafka.xml
-
XML.
K
- KeyDeserializer - Class in io.github.eocqrs.kafka.parameters
-
It's a wrapper for the `key.deserializer` kafka attribute.
- KeyDeserializer(Class<?>) - Constructor for class io.github.eocqrs.kafka.parameters.KeyDeserializer
-
Ctor.
- KeyDeserializer(String) - Constructor for class io.github.eocqrs.kafka.parameters.KeyDeserializer
-
Ctor.
- KeySerializer - Class in io.github.eocqrs.kafka.parameters
-
It's a wrapper for the `key.serializer` kafka attribute.
- KeySerializer(Class<?>) - Constructor for class io.github.eocqrs.kafka.parameters.KeySerializer
-
Ctor.
- KeySerializer(String) - Constructor for class io.github.eocqrs.kafka.parameters.KeySerializer
-
Ctor.
- KfAttrEnvelope - Class in io.github.eocqrs.kafka.parameters
-
It's a wrapper for a string value that can be converted to XML.
- KfAttrEnvelope(String, String) - Constructor for class io.github.eocqrs.kafka.parameters.KfAttrEnvelope
-
Ctor.
- KfCallback<K,
X> - Class in io.github.eocqrs.kafka.producer -
Kafka Producer with callback, decorator for
KafkaProducer. - KfCallback(ProducerSettings<K, X>, Callback) - Constructor for class io.github.eocqrs.kafka.producer.KfCallback
-
Settings ctor.
- KfCallback(KafkaProducer<K, X>, Callback) - Constructor for class io.github.eocqrs.kafka.producer.KfCallback
-
Primary ctor.
- KfConsumer<K,
X> - Class in io.github.eocqrs.kafka.consumer -
Kafka Consumer.
- KfConsumer(ConsumerSettings<K, X>) - Constructor for class io.github.eocqrs.kafka.consumer.KfConsumer
-
Ctor.
- KfConsumer(KafkaConsumer<K, X>) - Constructor for class io.github.eocqrs.kafka.consumer.KfConsumer
-
Ctor.
- KfConsumerParams - Class in io.github.eocqrs.kafka.consumer.settings
-
Kafka params for
KfConsumer. - KfConsumerParams() - Constructor for class io.github.eocqrs.kafka.consumer.settings.KfConsumerParams
- KfData<X> - Class in io.github.eocqrs.kafka.data
-
Kafka Message Data.
- KfData() - Constructor for class io.github.eocqrs.kafka.data.KfData
- KfDataized<X> - Class in io.github.eocqrs.kafka.data
-
Kafka Dataized data.
- KfDataized() - Constructor for class io.github.eocqrs.kafka.data.KfDataized
- KfFlexible<K,
X> - Class in io.github.eocqrs.kafka.parameters -
KfFlexibleSettings allow you to add custom settings.
- KfFlexible() - Constructor for class io.github.eocqrs.kafka.parameters.KfFlexible
- KfFlexibleEnvelope<K,
X> - Class in io.github.eocqrs.kafka.parameters -
Envelope for
ConsumerSettings. - KfFlexibleEnvelope(XML) - Constructor for class io.github.eocqrs.kafka.parameters.KfFlexibleEnvelope
-
Primary ctor.
- KfFlexibleEnvelope(Params) - Constructor for class io.github.eocqrs.kafka.parameters.KfFlexibleEnvelope
-
A constructor that takes a Settings object and converts it to XMLDocument.
- KfFlexibleEnvelope(String) - Constructor for class io.github.eocqrs.kafka.parameters.KfFlexibleEnvelope
-
A constructor that takes a String and converts it to ResourceOf.
- KfFlexibleEnvelope(Input) - Constructor for class io.github.eocqrs.kafka.parameters.KfFlexibleEnvelope
-
A constructor that takes an Input and converts it to XMLDocument.
- KfParams - Class in io.github.eocqrs.kafka.parameters
-
It's a collection of `
ParamsAttr` objects. - KfParams(ParamsAttr...) - Constructor for class io.github.eocqrs.kafka.parameters.KfParams
-
Ctor.
- KfProducer<K,
X> - Class in io.github.eocqrs.kafka.producer -
Kafka Producer.
- KfProducer(ProducerSettings<K, X>) - Constructor for class io.github.eocqrs.kafka.producer.KfProducer
-
Ctor.
- KfProducer(KafkaProducer<K, X>) - Constructor for class io.github.eocqrs.kafka.producer.KfProducer
-
Ctor.
- KfProducerParams - Class in io.github.eocqrs.kafka.producer.settings
-
Kafka Producer parameters for
KfProducer. - KfProducerParams() - Constructor for class io.github.eocqrs.kafka.producer.settings.KfProducerParams
- KfXmlFlexible<K,
X> - Class in io.github.eocqrs.kafka.xml -
Allow creating custom Consumer/Producer from XML.
- KfXmlFlexible(String) - Constructor for class io.github.eocqrs.kafka.xml.KfXmlFlexible
-
Ctor.
L
- LingerMs - Class in io.github.eocqrs.kafka.parameters
-
It's a wrapper for the `linger.ms` kafka attribute.
- LingerMs(String) - Constructor for class io.github.eocqrs.kafka.parameters.LingerMs
-
Ctor.
- lock() - Method in interface io.github.eocqrs.kafka.fake.storage.FkStorage
-
Deprecated.Locks storage to the current thread.
- lock() - Method in class io.github.eocqrs.kafka.fake.storage.InFile
-
Deprecated.
M
- MaxBlockMs - Class in io.github.eocqrs.kafka.parameters
-
It's a wrapper for the `max.block.ms` kafka attribute.
- MaxBlockMs(String) - Constructor for class io.github.eocqrs.kafka.parameters.MaxBlockMs
-
Ctor.
- MaxInFlightRq - Class in io.github.eocqrs.kafka.parameters
-
Wrapper for the `max.in.flight.requests.per.connection`.
- MaxInFlightRq(String) - Constructor for class io.github.eocqrs.kafka.parameters.MaxInFlightRq
-
Ctor.
- MaxPartitionFetchBytes - Class in io.github.eocqrs.kafka.parameters
-
It's a wrapper for the `max.partition.fetch.bytes` kafka attribute.
- MaxPartitionFetchBytes(String) - Constructor for class io.github.eocqrs.kafka.parameters.MaxPartitionFetchBytes
-
Ctor.
- MaxPollIntervalMs - Class in io.github.eocqrs.kafka.parameters
-
It's a wrapper for the `max.poll.interval.ms` kafka attribute.
- MaxPollIntervalMs(String) - Constructor for class io.github.eocqrs.kafka.parameters.MaxPollIntervalMs
-
Ctor.
- MaxPollRecords - Class in io.github.eocqrs.kafka.parameters
-
It's a wrapper for the `max.poll.records` kafka attribute.
- MaxPollRecords(String) - Constructor for class io.github.eocqrs.kafka.parameters.MaxPollRecords
-
Ctor.
- MaxRqSize - Class in io.github.eocqrs.kafka.parameters
-
It's a wrapper for the `max.request.size` kafka attribute.
- MaxRqSize(String) - Constructor for class io.github.eocqrs.kafka.parameters.MaxRqSize
-
Ctor.
N
- name - Variable in class io.github.eocqrs.kafka.parameters.KfAttrEnvelope
-
The name.
- name() - Method in class io.github.eocqrs.kafka.parameters.KfAttrEnvelope
- name() - Method in interface io.github.eocqrs.kafka.ParamsAttr
-
Returns the name of the current attribute.
- NameInCamelCase - Class in io.github.eocqrs.kafka.xml
-
It takes a string in the form of `com.example.foo.bar` and returns a string in the form of `comExampleFooBar`.
- NameInCamelCase() - Constructor for class io.github.eocqrs.kafka.xml.NameInCamelCase
P
- Params - Interface in io.github.eocqrs.kafka
-
Settings attribute.
- ParamsAttr - Interface in io.github.eocqrs.kafka
-
Kafka property.
- partition() - Method in class io.github.eocqrs.kafka.data.KfData
- partition() - Method in interface io.github.eocqrs.kafka.Data
-
Partition.
- PartitionAssignmentStrategy - Class in io.github.eocqrs.kafka.parameters
-
It's a wrapper for the `partition.assignment.strategy` kafka attribute.
- PartitionAssignmentStrategy(String) - Constructor for class io.github.eocqrs.kafka.parameters.PartitionAssignmentStrategy
-
Ctor.
- producer() - Method in class io.github.eocqrs.kafka.parameters.KfFlexible
- producer() - Method in interface io.github.eocqrs.kafka.ProducerSettings
-
Kafka Producer.
- producer() - Method in class io.github.eocqrs.kafka.xml.KfXmlFlexible
- Producer<K,
X> - Interface in io.github.eocqrs.kafka -
Producer.
- ProducerSettings<K,
X> - Interface in io.github.eocqrs.kafka -
Producer Settings.
R
- ReceiveBufferBytes - Class in io.github.eocqrs.kafka.parameters
-
It's a wrapper for the `receive.buffer.bytes` kafka attribute.
- ReceiveBufferBytes(String) - Constructor for class io.github.eocqrs.kafka.parameters.ReceiveBufferBytes
-
Ctor.
- records(String, Duration) - Method in class io.github.eocqrs.kafka.consumer.KfConsumer
- records(String, Duration) - Method in interface io.github.eocqrs.kafka.Consumer
-
Fetch Records.
- records(String, Duration) - Method in class io.github.eocqrs.kafka.fake.FkConsumer
- Retries - Class in io.github.eocqrs.kafka.parameters
-
It's a wrapper for the `retries` kafka attribute.
- Retries(String) - Constructor for class io.github.eocqrs.kafka.parameters.Retries
-
Ctor.
- RetryBackoffMs - Class in io.github.eocqrs.kafka.parameters
-
It's a wrapper for the `retry.backoff.ms` kafka attribute.
- RetryBackoffMs(String) - Constructor for class io.github.eocqrs.kafka.parameters.RetryBackoffMs
-
Ctor.
S
- SaslJaasConfig - Class in io.github.eocqrs.kafka.parameters
-
It's a wrapper for the `sasl.jaas.config` kafka attribute.
- SaslJaasConfig(String) - Constructor for class io.github.eocqrs.kafka.parameters.SaslJaasConfig
-
Ctor.
- SaslMechanism - Class in io.github.eocqrs.kafka.parameters
-
It's a wrapper for the `sasl.mechanism` kafka attribute.
- SaslMechanism(String) - Constructor for class io.github.eocqrs.kafka.parameters.SaslMechanism
-
Ctor.
- SecurityProtocol - Class in io.github.eocqrs.kafka.parameters
-
It's a wrapper for the `security.protocol` kafka attribute.
- SecurityProtocol(String) - Constructor for class io.github.eocqrs.kafka.parameters.SecurityProtocol
-
Ctor.
- send(K, Data<X>) - Method in class io.github.eocqrs.kafka.fake.FkProducer
- send(K, Data<X>) - Method in class io.github.eocqrs.kafka.producer.KfCallback
- send(K, Data<X>) - Method in class io.github.eocqrs.kafka.producer.KfProducer
- send(K, Data<X>) - Method in interface io.github.eocqrs.kafka.Producer
-
Send data.
- SendBufferBytes - Class in io.github.eocqrs.kafka.parameters
-
It's a wrapper for the `send.buffer.bytes` kafka attribute.
- SendBufferBytes(String) - Constructor for class io.github.eocqrs.kafka.parameters.SendBufferBytes
-
Ctor.
- SessionTimeoutMs - Class in io.github.eocqrs.kafka.parameters
-
It's a wrapper for the `session.timeout.ms` kafka attribute.
- SessionTimeoutMs(String) - Constructor for class io.github.eocqrs.kafka.parameters.SessionTimeoutMs
-
Ctor.
- settings - Variable in class io.github.eocqrs.kafka.parameters.KfFlexibleEnvelope
-
Settings in XML.
- subscribe(String...) - Method in class io.github.eocqrs.kafka.consumer.KfConsumer
- subscribe(String...) - Method in interface io.github.eocqrs.kafka.Consumer
-
Subscribe.
- subscribe(String...) - Method in class io.github.eocqrs.kafka.fake.FkConsumer
- subscribe(Collection<String>) - Method in class io.github.eocqrs.kafka.consumer.KfConsumer
- subscribe(Collection<String>) - Method in interface io.github.eocqrs.kafka.Consumer
-
Subscribe.
- subscribe(Collection<String>) - Method in class io.github.eocqrs.kafka.fake.FkConsumer
- subscribe(ConsumerRebalanceListener, String...) - Method in class io.github.eocqrs.kafka.consumer.KfConsumer
- subscribe(ConsumerRebalanceListener, String...) - Method in interface io.github.eocqrs.kafka.Consumer
-
Subscribe.
- subscribe(ConsumerRebalanceListener, String...) - Method in class io.github.eocqrs.kafka.fake.FkConsumer
T
- topic() - Method in class io.github.eocqrs.kafka.data.KfData
- topic() - Method in interface io.github.eocqrs.kafka.Data
-
Topic.
- toString() - Method in class io.github.eocqrs.kafka.xml.NameInCamelCase
U
- unlock() - Method in interface io.github.eocqrs.kafka.fake.storage.FkStorage
-
Deprecated.Unlock storage.
- unlock() - Method in class io.github.eocqrs.kafka.fake.storage.InFile
-
Deprecated.
- unsubscribe() - Method in class io.github.eocqrs.kafka.consumer.KfConsumer
- unsubscribe() - Method in interface io.github.eocqrs.kafka.Consumer
-
Unsubscribe.
- unsubscribe() - Method in class io.github.eocqrs.kafka.fake.FkConsumer
V
- value - Variable in class io.github.eocqrs.kafka.parameters.KfAttrEnvelope
-
The value.
- value() - Method in class io.github.eocqrs.kafka.parameters.KfAttrEnvelope
- value() - Method in interface io.github.eocqrs.kafka.ParamsAttr
- ValueDeserializer - Class in io.github.eocqrs.kafka.parameters
-
It's a wrapper for the `value.deserializer` kafka attribute.
- ValueDeserializer(Class<?>) - Constructor for class io.github.eocqrs.kafka.parameters.ValueDeserializer
-
Ctor.
- ValueDeserializer(String) - Constructor for class io.github.eocqrs.kafka.parameters.ValueDeserializer
-
Ctor.
- ValueSerializer - Class in io.github.eocqrs.kafka.parameters
-
It's a wrapper for the `value.serializer` kafka attribute.
- ValueSerializer(Class<?>) - Constructor for class io.github.eocqrs.kafka.parameters.ValueSerializer
-
Ctor.
- ValueSerializer(String) - Constructor for class io.github.eocqrs.kafka.parameters.ValueSerializer
-
Ctor.
W
- Wakeup - Class in io.github.eocqrs.kafka.act
-
Wakeup of Kafka Consumer.
- Wakeup() - Constructor for class io.github.eocqrs.kafka.act.Wakeup
- withDataset(Object, Data<X>) - Method in interface io.github.eocqrs.kafka.fake.FkBroker
-
Adds Dataset.
- withDataset(Object, Data<X>) - Method in class io.github.eocqrs.kafka.fake.InXml
- withTopics(String...) - Method in interface io.github.eocqrs.kafka.fake.FkBroker
-
Adds topics.
- withTopics(String...) - Method in class io.github.eocqrs.kafka.fake.InXml
X
- xml() - Method in interface io.github.eocqrs.kafka.fake.storage.FkStorage
-
Deprecated.Full XML.
- xml() - Method in class io.github.eocqrs.kafka.fake.storage.InFile
-
Deprecated.
All Classes and Interfaces|All Packages
FkStorage