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

A

ack() - Method in class io.smallrye.reactive.messaging.kafka.IncomingKafkaRecord
 
ack() - Method in class io.smallrye.reactive.messaging.kafka.OutgoingKafkaRecord
 
asJsonObject(Config) - Static method in class io.smallrye.reactive.messaging.kafka.impl.JsonHelper
 
asKafkaConfiguration(Map<String, String>) - Static method in class io.smallrye.reactive.messaging.kafka.impl.ConfigurationCleaner
 

B

build() - Method in class io.smallrye.reactive.messaging.kafka.OutgoingKafkaRecordMetadata.OutgoingKafkaRecordMetadataBuilder
 
builder() - Static method in class io.smallrye.reactive.messaging.kafka.OutgoingKafkaRecordMetadata
 

C

canConvert(Message<?>, Type) - Method in class io.smallrye.reactive.messaging.kafka.converters.ConsumerRecordConverter
 
canConvert(Message<?>, Type) - Method in class io.smallrye.reactive.messaging.kafka.converters.RecordConverter
 
capture(KafkaReadStream<?, ?>) - Method in class io.smallrye.reactive.messaging.kafka.commit.ContextHolder
 
CE_CONTENT_TYPE_PREFIX - Static variable in class io.smallrye.reactive.messaging.kafka.impl.ce.KafkaCloudEventHelper
 
CE_HEADER_PREFIX - Static variable in class io.smallrye.reactive.messaging.kafka.impl.ce.KafkaCloudEventHelper
 
CE_KAFKA_KEY - Static variable in interface io.smallrye.reactive.messaging.kafka.IncomingKafkaCloudEventMetadata
Extension - attribute name associated with the record's key.
CE_KAFKA_TOPIC - Static variable in interface io.smallrye.reactive.messaging.kafka.IncomingKafkaCloudEventMetadata
Extension - attribute name associated with the record's topic.
cleanupConsumerConfiguration(Map<String, String>) - Static method in class io.smallrye.reactive.messaging.kafka.impl.ConfigurationCleaner
 
cleanupProducerConfiguration(JsonObject) - Static method in class io.smallrye.reactive.messaging.kafka.impl.ConfigurationCleaner
 
cleanupProducerConfiguration(Map<String, String>) - Static method in class io.smallrye.reactive.messaging.kafka.impl.ConfigurationCleaner
 
clearCache() - Static method in class io.smallrye.reactive.messaging.kafka.commit.KafkaThrottledLatestProcessedCommit
 
close() - Method in class io.smallrye.reactive.messaging.kafka.fault.DeserializerWrapper
 
closeQuietly() - Method in class io.smallrye.reactive.messaging.kafka.impl.KafkaSink
 
closeQuietly() - Method in class io.smallrye.reactive.messaging.kafka.impl.KafkaSource
 
commitStrategyForChannel(String, String) - Method in interface io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging
 
commitStrategyForChannel(String, String) - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging_$logger
 
commitStrategyForChannel$str() - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging_$logger
 
config - Variable in class io.smallrye.reactive.messaging.kafka.KafkaConnectorCommonConfiguration
 
config() - Method in class io.smallrye.reactive.messaging.kafka.KafkaConnectorCommonConfiguration
 
configServers(String, String) - Method in interface io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging
 
configServers(String, String) - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging_$logger
 
configServers$str() - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging_$logger
 
ConfigurationCleaner - Class in io.smallrye.reactive.messaging.kafka.impl
 
configure(Map<String, ?>, boolean) - Method in class io.smallrye.reactive.messaging.kafka.fault.DeserializerWrapper
Delegates to the underlying deserializer instance.
configuredPattern(String, String) - Method in interface io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging
 
configuredPattern(String, String) - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging_$logger
 
configuredPattern$str() - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging_$logger
 
configuredTopics(String, Set<String>) - Method in interface io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging
 
configuredTopics(String, Set<String>) - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging_$logger
 
configuredTopics$str() - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging_$logger
 
CONNECTOR_NAME - Static variable in class io.smallrye.reactive.messaging.kafka.KafkaConnector
 
consumer() - Method in class io.smallrye.reactive.messaging.kafka.KafkaCDIEvents
 
ConsumerRecordConverter - Class in io.smallrye.reactive.messaging.kafka.converters
Convert an incoming Kafka message into a ConsumerRecord.
ConsumerRecordConverter() - Constructor for class io.smallrye.reactive.messaging.kafka.converters.ConsumerRecordConverter
 
context - Variable in class io.smallrye.reactive.messaging.kafka.commit.ContextHolder
 
ContextHolder - Class in io.smallrye.reactive.messaging.kafka.commit
A class holding a vert.x context to make sure methods are always run from the same one.
ContextHolder(Vertx, int) - Constructor for class io.smallrye.reactive.messaging.kafka.commit.ContextHolder
 
convert(Message<?>, Type) - Method in class io.smallrye.reactive.messaging.kafka.converters.ConsumerRecordConverter
 
convert(Message<?>, Type) - Method in class io.smallrye.reactive.messaging.kafka.converters.RecordConverter
 
create(Vertx, KafkaConsumer<?, ?>, String, KafkaConnectorIncomingConfiguration, KafkaSource<?, ?>) - Static method in class io.smallrye.reactive.messaging.kafka.commit.KafkaThrottledLatestProcessedCommit
 
create(Vertx, Map<String, String>, KafkaConnectorIncomingConfiguration, KafkaSource<?, ?>, KafkaCDIEvents) - Static method in class io.smallrye.reactive.messaging.kafka.fault.KafkaDeadLetterQueue
 
createAdminClient(Vertx, Map<String, Object>, String, boolean) - Static method in class io.smallrye.reactive.messaging.kafka.impl.KafkaAdminHelper
 
createBinaryRecord(Message<?>, String, OutgoingKafkaRecordMetadata<?>, OutgoingCloudEventMetadata<?>, KafkaConnectorOutgoingConfiguration) - Static method in class io.smallrye.reactive.messaging.kafka.impl.ce.KafkaCloudEventHelper
 
createFromBinaryCloudEvent(KafkaConsumerRecord<?, T>) - Static method in class io.smallrye.reactive.messaging.kafka.impl.ce.KafkaCloudEventHelper
 
createFromStructuredCloudEvent(KafkaConsumerRecord<K, T>) - Static method in class io.smallrye.reactive.messaging.kafka.impl.ce.KafkaCloudEventHelper
 
createStructuredRecord(Message<?>, String, OutgoingKafkaRecordMetadata<?>, OutgoingCloudEventMetadata<?>, KafkaConnectorOutgoingConfiguration) - Static method in class io.smallrye.reactive.messaging.kafka.impl.ce.KafkaCloudEventHelper
 

D

DEAD_LETTER_CAUSE - Static variable in class io.smallrye.reactive.messaging.kafka.fault.KafkaDeadLetterQueue
 
DEAD_LETTER_OFFSET - Static variable in class io.smallrye.reactive.messaging.kafka.fault.KafkaDeadLetterQueue
 
DEAD_LETTER_PARTITION - Static variable in class io.smallrye.reactive.messaging.kafka.fault.KafkaDeadLetterQueue
 
DEAD_LETTER_REASON - Static variable in class io.smallrye.reactive.messaging.kafka.fault.KafkaDeadLetterQueue
 
DEAD_LETTER_TOPIC - Static variable in class io.smallrye.reactive.messaging.kafka.fault.KafkaDeadLetterQueue
 
deadLetterConfig(String, String, String) - Method in interface io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging
 
deadLetterConfig(String, String, String) - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging_$logger
 
deadLetterConfig$str() - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging_$logger
 
DefaultIncomingKafkaCloudEventMetadata<K,T> - Class in io.smallrye.reactive.messaging.kafka.impl.ce
 
DefaultIncomingKafkaCloudEventMetadata(IncomingCloudEventMetadata<T>) - Constructor for class io.smallrye.reactive.messaging.kafka.impl.ce.DefaultIncomingKafkaCloudEventMetadata
 
DESERIALIZATION_FAILURE_CAUSE - Static variable in class io.smallrye.reactive.messaging.kafka.fault.DeserializerWrapper
Header name for deserialization failure cause if any.
DESERIALIZATION_FAILURE_DATA - Static variable in class io.smallrye.reactive.messaging.kafka.fault.DeserializerWrapper
Header name passing the data that was not able to be deserialized.
DESERIALIZATION_FAILURE_DESERIALIZER - Static variable in class io.smallrye.reactive.messaging.kafka.fault.DeserializerWrapper
Header name passing the class name of the underlying deserializer.
DESERIALIZATION_FAILURE_IS_KEY - Static variable in class io.smallrye.reactive.messaging.kafka.fault.DeserializerWrapper
Header name used when the deserialization failure happened on a key.
DESERIALIZATION_FAILURE_REASON - Static variable in class io.smallrye.reactive.messaging.kafka.fault.DeserializerWrapper
Header name for deserialization failure message.
DESERIALIZATION_FAILURE_TOPIC - Static variable in class io.smallrye.reactive.messaging.kafka.fault.DeserializerWrapper
Header name for the topic of the incoming message when a deserialization failure happen.
DeserializationFailureHandler<T> - Interface in io.smallrye.reactive.messaging.kafka
Bean invoked on Kafka deserialization failure.
deserializationFailureHandlerFailure(String, Throwable) - Method in interface io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging
 
deserializationFailureHandlerFailure(String, Throwable) - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging_$logger
 
deserializationFailureHandlerFailure$str() - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging_$logger
 
deserialize(String, byte[]) - Method in class io.smallrye.reactive.messaging.kafka.fault.DeserializerWrapper
 
deserialize(String, Headers, byte[]) - Method in class io.smallrye.reactive.messaging.kafka.fault.DeserializerWrapper
 
DeserializerWrapper<T> - Class in io.smallrye.reactive.messaging.kafka.fault
Wraps a delegate deserializer to handle config and deserialization failures.
DeserializerWrapper(String, boolean, DeserializationFailureHandler<T>, KafkaSource<?, ?>) - Constructor for class io.smallrye.reactive.messaging.kafka.fault.DeserializerWrapper
 
disableAutoCommit(String) - Method in interface io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging
 
disableAutoCommit(String) - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging_$logger
 
disableAutoCommit$str() - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging_$logger
 
disableThrottledCommitStrategyHealthCheck(String) - Method in interface io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging
 
disableThrottledCommitStrategyHealthCheck(String) - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging_$logger
 
disableThrottledCommitStrategyHealthCheck$str() - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging_$logger
 

E

errorWhileClosingWriteStream(Throwable) - Method in interface io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging
 
errorWhileClosingWriteStream(Throwable) - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging_$logger
 
errorWhileClosingWriteStream$str() - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging_$logger
 
ex - Static variable in interface io.smallrye.reactive.messaging.kafka.i18n.KafkaExceptions
 
exceptionOnClose(Throwable) - Method in interface io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging
 
exceptionOnClose(Throwable) - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging_$logger
 
exceptionOnClose$str() - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging_$logger
 
executedConsumerAssignedRebalanceListener(String) - Method in interface io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging
 
executedConsumerAssignedRebalanceListener(String) - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging_$logger
 
executedConsumerAssignedRebalanceListener$str() - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging_$logger
 
executedConsumerRevokedRebalanceListener(String) - Method in interface io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging
 
executedConsumerRevokedRebalanceListener(String) - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging_$logger
 
executedConsumerRevokedRebalanceListener$str() - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging_$logger
 
executingConsumerAssignedRebalanceListener(String) - Method in interface io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging
 
executingConsumerAssignedRebalanceListener(String) - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging_$logger
 
executingConsumerAssignedRebalanceListener$str() - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging_$logger
 
executingConsumerRevokedRebalanceListener(String) - Method in interface io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging
 
executingConsumerRevokedRebalanceListener(String) - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging_$logger
 
executingConsumerRevokedRebalanceListener$str() - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging_$logger
 

F

failureReported(Set<String>, Throwable) - Method in interface io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging
 
failureReported(Set<String>, Throwable) - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging_$logger
 
failureReported$str() - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging_$logger
 
failureReportedDuringRebalance(Set<String>, Throwable) - Method in interface io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging
 
failureReportedDuringRebalance(Set<String>, Throwable) - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging_$logger
 
failureReportedDuringRebalance$str() - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging_$logger
 
from(String) - Static method in enum io.smallrye.reactive.messaging.kafka.commit.KafkaCommitHandler.Strategy
 
from(String) - Static method in enum io.smallrye.reactive.messaging.kafka.fault.KafkaFailureHandler.Strategy
 
from(Message<T>) - Static method in interface io.smallrye.reactive.messaging.kafka.KafkaRecord
 
from(Message<T>) - Static method in class io.smallrye.reactive.messaging.kafka.OutgoingKafkaRecord
 

G

get(Headers, String) - Method in class io.smallrye.reactive.messaging.kafka.tracing.HeaderExtractAdapter
 
getAck() - Method in class io.smallrye.reactive.messaging.kafka.IncomingKafkaRecord
 
getAck() - Method in class io.smallrye.reactive.messaging.kafka.OutgoingKafkaRecord
 
getAcks() - Method in class io.smallrye.reactive.messaging.kafka.KafkaConnectorOutgoingConfiguration
Gets the acks value from the configuration.
getAutoOffsetReset() - Method in class io.smallrye.reactive.messaging.kafka.KafkaConnectorIncomingConfiguration
Gets the auto.offset.reset value from the configuration.
getBootstrapServers() - Method in class io.smallrye.reactive.messaging.kafka.KafkaConnectorCommonConfiguration
Gets the bootstrap.servers value from the configuration.
getBroadcast() - Method in class io.smallrye.reactive.messaging.kafka.KafkaConnectorIncomingConfiguration
Gets the broadcast value from the configuration.
getBufferMemory() - Method in class io.smallrye.reactive.messaging.kafka.KafkaConnectorOutgoingConfiguration
Gets the buffer.memory value from the configuration.
getChannel() - Method in class io.smallrye.reactive.messaging.kafka.KafkaConnectorCommonConfiguration
 
getCloudEventMode(KafkaConsumerRecord<?, ?>) - Static method in class io.smallrye.reactive.messaging.kafka.impl.ce.KafkaCloudEventHelper
 
getCloudEvents() - Method in class io.smallrye.reactive.messaging.kafka.KafkaConnectorCommonConfiguration
Gets the cloud-events value from the configuration.
getCloudEventsDataContentType() - Method in class io.smallrye.reactive.messaging.kafka.KafkaConnectorOutgoingConfiguration
Gets the cloud-events-data-content-type value from the configuration.
getCloudEventsDataSchema() - Method in class io.smallrye.reactive.messaging.kafka.KafkaConnectorOutgoingConfiguration
Gets the cloud-events-data-schema value from the configuration.
getCloudEventsInsertTimestamp() - Method in class io.smallrye.reactive.messaging.kafka.KafkaConnectorOutgoingConfiguration
Gets the cloud-events-insert-timestamp value from the configuration.
getCloudEventsMode() - Method in class io.smallrye.reactive.messaging.kafka.KafkaConnectorOutgoingConfiguration
Gets the cloud-events-mode value from the configuration.
getCloudEventsSource() - Method in class io.smallrye.reactive.messaging.kafka.KafkaConnectorOutgoingConfiguration
Gets the cloud-events-source value from the configuration.
getCloudEventsSubject() - Method in class io.smallrye.reactive.messaging.kafka.KafkaConnectorOutgoingConfiguration
Gets the cloud-events-subject value from the configuration.
getCloudEventsType() - Method in class io.smallrye.reactive.messaging.kafka.KafkaConnectorOutgoingConfiguration
Gets the cloud-events-type value from the configuration.
getCommitStrategy() - Method in class io.smallrye.reactive.messaging.kafka.KafkaConnectorIncomingConfiguration
Gets the commit-strategy value from the configuration.
getConsumer() - Method in class io.smallrye.reactive.messaging.kafka.impl.KafkaSource
For testing purpose only
getConsumerRebalanceListenerName() - Method in class io.smallrye.reactive.messaging.kafka.KafkaConnectorIncomingConfiguration
Gets the consumer-rebalance-listener.name value from the configuration.
getContext() - Method in class io.smallrye.reactive.messaging.kafka.commit.ContextHolder
 
getData() - Method in class io.smallrye.reactive.messaging.kafka.impl.ce.DefaultIncomingKafkaCloudEventMetadata
 
getDataContentType() - Method in class io.smallrye.reactive.messaging.kafka.impl.ce.DefaultIncomingKafkaCloudEventMetadata
 
getDataSchema() - Method in class io.smallrye.reactive.messaging.kafka.impl.ce.DefaultIncomingKafkaCloudEventMetadata
 
getDeadLetterQueueKeySerializer() - Method in class io.smallrye.reactive.messaging.kafka.KafkaConnectorIncomingConfiguration
Gets the dead-letter-queue.key.serializer value from the configuration.
getDeadLetterQueueTopic() - Method in class io.smallrye.reactive.messaging.kafka.KafkaConnectorIncomingConfiguration
Gets the dead-letter-queue.topic value from the configuration.
getDeadLetterQueueValueSerializer() - Method in class io.smallrye.reactive.messaging.kafka.KafkaConnectorIncomingConfiguration
Gets the dead-letter-queue.value.serializer value from the configuration.
getEnableAutoCommit() - Method in class io.smallrye.reactive.messaging.kafka.KafkaConnectorIncomingConfiguration
Gets the enable.auto.commit value from the configuration.
getExtension(String) - Method in class io.smallrye.reactive.messaging.kafka.impl.ce.DefaultIncomingKafkaCloudEventMetadata
 
getExtensions() - Method in class io.smallrye.reactive.messaging.kafka.impl.ce.DefaultIncomingKafkaCloudEventMetadata
 
getFailureStrategy() - Method in class io.smallrye.reactive.messaging.kafka.KafkaConnectorIncomingConfiguration
Gets the failure-strategy value from the configuration.
getFetchMinBytes() - Method in class io.smallrye.reactive.messaging.kafka.KafkaConnectorIncomingConfiguration
Gets the fetch.min.bytes value from the configuration.
getFromAlias(String, Class<T>) - Method in class io.smallrye.reactive.messaging.kafka.KafkaConnectorCommonConfiguration
Retrieves the value stored for the given alias.
getFromAliasWithDefaultValue(String, Class<T>, T) - Method in class io.smallrye.reactive.messaging.kafka.KafkaConnectorCommonConfiguration
Retrieves the value stored for the given alias.
getGroupId() - Method in class io.smallrye.reactive.messaging.kafka.KafkaConnectorIncomingConfiguration
Gets the group.id value from the configuration.
getHeaders() - Method in class io.smallrye.reactive.messaging.kafka.IncomingKafkaRecord
 
getHeaders() - Method in class io.smallrye.reactive.messaging.kafka.IncomingKafkaRecordMetadata
 
getHeaders() - Method in interface io.smallrye.reactive.messaging.kafka.KafkaMessageMetadata
 
getHeaders() - Method in interface io.smallrye.reactive.messaging.kafka.KafkaRecord
 
getHeaders() - Method in class io.smallrye.reactive.messaging.kafka.OutgoingKafkaRecord
 
getHeaders() - Method in class io.smallrye.reactive.messaging.kafka.OutgoingKafkaRecordMetadata
 
getHealthEnabled() - Method in class io.smallrye.reactive.messaging.kafka.KafkaConnectorCommonConfiguration
Gets the health-enabled value from the configuration.
getHealthReadinessEnabled() - Method in class io.smallrye.reactive.messaging.kafka.KafkaConnectorCommonConfiguration
Gets the health-readiness-enabled value from the configuration.
getHealthReadinessTimeout() - Method in class io.smallrye.reactive.messaging.kafka.KafkaConnectorCommonConfiguration
Gets the health-readiness-timeout value from the configuration.
getId() - Method in class io.smallrye.reactive.messaging.kafka.impl.ce.DefaultIncomingKafkaCloudEventMetadata
 
getKey() - Method in interface io.smallrye.reactive.messaging.kafka.IncomingKafkaCloudEventMetadata
 
getKey() - Method in class io.smallrye.reactive.messaging.kafka.IncomingKafkaRecord
 
getKey() - Method in class io.smallrye.reactive.messaging.kafka.IncomingKafkaRecordMetadata
 
getKey() - Method in class io.smallrye.reactive.messaging.kafka.KafkaConnectorOutgoingConfiguration
Gets the key value from the configuration.
getKey() - Method in interface io.smallrye.reactive.messaging.kafka.KafkaMessageMetadata
 
getKey() - Method in interface io.smallrye.reactive.messaging.kafka.KafkaRecord
 
getKey() - Method in class io.smallrye.reactive.messaging.kafka.OutgoingKafkaRecord
 
getKey() - Method in class io.smallrye.reactive.messaging.kafka.OutgoingKafkaRecordMetadata
 
getKeyDeserializationFailureHandler() - Method in class io.smallrye.reactive.messaging.kafka.KafkaConnectorIncomingConfiguration
Gets the key-deserialization-failure-handler value from the configuration.
getKeyDeserializer() - Method in class io.smallrye.reactive.messaging.kafka.KafkaConnectorIncomingConfiguration
Gets the key.deserializer value from the configuration.
getKeySerializer() - Method in class io.smallrye.reactive.messaging.kafka.KafkaConnectorOutgoingConfiguration
Gets the key.serializer value from the configuration.
getLiveness() - Method in class io.smallrye.reactive.messaging.kafka.KafkaConnector
 
getLoggingLocale() - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaExceptions_$bundle
 
getLoggingLocale() - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging_$logger
 
getLoggingLocale() - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaMessages_$bundle
 
getMaxInflightMessages() - Method in class io.smallrye.reactive.messaging.kafka.KafkaConnectorOutgoingConfiguration
Gets the max-inflight-messages value from the configuration.
getMetadata() - Method in class io.smallrye.reactive.messaging.kafka.IncomingKafkaRecord
 
getMetadata() - Method in class io.smallrye.reactive.messaging.kafka.OutgoingKafkaRecord
 
getNack() - Method in class io.smallrye.reactive.messaging.kafka.IncomingKafkaRecord
 
getNack() - Method in class io.smallrye.reactive.messaging.kafka.OutgoingKafkaRecord
 
getOffset() - Method in class io.smallrye.reactive.messaging.kafka.IncomingKafkaRecord
 
getOffset() - Method in class io.smallrye.reactive.messaging.kafka.IncomingKafkaRecordMetadata
 
getPartition() - Method in class io.smallrye.reactive.messaging.kafka.IncomingKafkaRecord
 
getPartition() - Method in class io.smallrye.reactive.messaging.kafka.IncomingKafkaRecordMetadata
 
getPartition() - Method in class io.smallrye.reactive.messaging.kafka.KafkaConnectorOutgoingConfiguration
Gets the partition value from the configuration.
getPartition() - Method in interface io.smallrye.reactive.messaging.kafka.KafkaMessageMetadata
 
getPartition() - Method in interface io.smallrye.reactive.messaging.kafka.KafkaRecord
 
getPartition() - Method in class io.smallrye.reactive.messaging.kafka.OutgoingKafkaRecord
 
getPartition() - Method in class io.smallrye.reactive.messaging.kafka.OutgoingKafkaRecordMetadata
 
getPartitions() - Method in class io.smallrye.reactive.messaging.kafka.KafkaConnectorIncomingConfiguration
Gets the partitions value from the configuration.
getPattern() - Method in class io.smallrye.reactive.messaging.kafka.KafkaConnectorIncomingConfiguration
Gets the pattern value from the configuration.
getPayload() - Method in class io.smallrye.reactive.messaging.kafka.IncomingKafkaRecord
 
getPayload() - Method in class io.smallrye.reactive.messaging.kafka.OutgoingKafkaRecord
 
getPublisherBuilder(Config) - Method in class io.smallrye.reactive.messaging.kafka.KafkaConnector
 
getReadiness() - Method in class io.smallrye.reactive.messaging.kafka.KafkaConnector
 
getRecord() - Method in class io.smallrye.reactive.messaging.kafka.IncomingKafkaRecordMetadata
 
getRetries() - Method in class io.smallrye.reactive.messaging.kafka.KafkaConnectorOutgoingConfiguration
Gets the retries value from the configuration.
getRetry() - Method in class io.smallrye.reactive.messaging.kafka.KafkaConnectorIncomingConfiguration
Gets the retry value from the configuration.
getRetryAttempts() - Method in class io.smallrye.reactive.messaging.kafka.KafkaConnectorIncomingConfiguration
Gets the retry-attempts value from the configuration.
getRetryMaxWait() - Method in class io.smallrye.reactive.messaging.kafka.KafkaConnectorIncomingConfiguration
Gets the retry-max-wait value from the configuration.
getSink() - Method in class io.smallrye.reactive.messaging.kafka.impl.KafkaSink
 
getSource() - Method in class io.smallrye.reactive.messaging.kafka.impl.ce.DefaultIncomingKafkaCloudEventMetadata
 
getSpecVersion() - Method in class io.smallrye.reactive.messaging.kafka.impl.ce.DefaultIncomingKafkaCloudEventMetadata
 
getStream() - Method in class io.smallrye.reactive.messaging.kafka.impl.KafkaSource
 
getSubject() - Method in class io.smallrye.reactive.messaging.kafka.impl.ce.DefaultIncomingKafkaCloudEventMetadata
 
getSubscriberBuilder(Config) - Method in class io.smallrye.reactive.messaging.kafka.KafkaConnector
 
GETTER - Static variable in class io.smallrye.reactive.messaging.kafka.tracing.HeaderExtractAdapter
 
getThrottledUnprocessedRecordMaxAgeMs() - Method in class io.smallrye.reactive.messaging.kafka.KafkaConnectorIncomingConfiguration
Gets the throttled.unprocessed-record-max-age.ms value from the configuration.
getTimeStamp() - Method in class io.smallrye.reactive.messaging.kafka.impl.ce.DefaultIncomingKafkaCloudEventMetadata
 
getTimestamp() - Method in class io.smallrye.reactive.messaging.kafka.IncomingKafkaRecord
 
getTimestamp() - Method in class io.smallrye.reactive.messaging.kafka.IncomingKafkaRecordMetadata
 
getTimestamp() - Method in interface io.smallrye.reactive.messaging.kafka.KafkaMessageMetadata
 
getTimestamp() - Method in interface io.smallrye.reactive.messaging.kafka.KafkaRecord
 
getTimestamp() - Method in class io.smallrye.reactive.messaging.kafka.OutgoingKafkaRecord
 
getTimestamp() - Method in class io.smallrye.reactive.messaging.kafka.OutgoingKafkaRecordMetadata
 
getTimestampType() - Method in class io.smallrye.reactive.messaging.kafka.IncomingKafkaRecordMetadata
 
getTopic() - Method in interface io.smallrye.reactive.messaging.kafka.IncomingKafkaCloudEventMetadata
 
getTopic() - Method in class io.smallrye.reactive.messaging.kafka.IncomingKafkaRecord
 
getTopic() - Method in class io.smallrye.reactive.messaging.kafka.IncomingKafkaRecordMetadata
 
getTopic() - Method in class io.smallrye.reactive.messaging.kafka.KafkaConnectorCommonConfiguration
Gets the topic value from the configuration.
getTopic() - Method in interface io.smallrye.reactive.messaging.kafka.KafkaMessageMetadata
 
getTopic() - Method in interface io.smallrye.reactive.messaging.kafka.KafkaRecord
 
getTopic() - Method in class io.smallrye.reactive.messaging.kafka.OutgoingKafkaRecord
 
getTopic() - Method in class io.smallrye.reactive.messaging.kafka.OutgoingKafkaRecordMetadata
 
getTopics() - Method in class io.smallrye.reactive.messaging.kafka.KafkaConnectorIncomingConfiguration
Gets the topics value from the configuration.
getTracingEnabled() - Method in class io.smallrye.reactive.messaging.kafka.KafkaConnectorCommonConfiguration
Gets the tracing-enabled value from the configuration.
getType() - Method in class io.smallrye.reactive.messaging.kafka.impl.ce.DefaultIncomingKafkaCloudEventMetadata
 
getValueDeserializationFailureHandler() - Method in class io.smallrye.reactive.messaging.kafka.KafkaConnectorIncomingConfiguration
Gets the value-deserialization-failure-handler value from the configuration.
getValueDeserializer() - Method in class io.smallrye.reactive.messaging.kafka.KafkaConnectorIncomingConfiguration
Gets the value.deserializer value from the configuration.
getValueSerializer() - Method in class io.smallrye.reactive.messaging.kafka.KafkaConnectorOutgoingConfiguration
Gets the value.serializer value from the configuration.
getWaitForWriteCompletion() - Method in class io.smallrye.reactive.messaging.kafka.KafkaConnectorOutgoingConfiguration
Gets the waitForWriteCompletion value from the configuration.

H

handle(IncomingKafkaRecord<K, V>) - Method in interface io.smallrye.reactive.messaging.kafka.commit.KafkaCommitHandler
 
handle(IncomingKafkaRecord<K, V>) - Method in class io.smallrye.reactive.messaging.kafka.commit.KafkaIgnoreCommit
 
handle(IncomingKafkaRecord<K, V>) - Method in class io.smallrye.reactive.messaging.kafka.commit.KafkaLatestCommit
 
handle(IncomingKafkaRecord<K, V>) - Method in class io.smallrye.reactive.messaging.kafka.commit.KafkaThrottledLatestProcessedCommit
A message has been acknowledged.
handle(IncomingKafkaRecord<K, V>, Throwable) - Method in class io.smallrye.reactive.messaging.kafka.fault.KafkaDeadLetterQueue
 
handle(IncomingKafkaRecord<K, V>, Throwable) - Method in class io.smallrye.reactive.messaging.kafka.fault.KafkaFailStop
 
handle(IncomingKafkaRecord<K, V>, Throwable) - Method in interface io.smallrye.reactive.messaging.kafka.fault.KafkaFailureHandler
 
handle(IncomingKafkaRecord<K, V>, Throwable) - Method in class io.smallrye.reactive.messaging.kafka.fault.KafkaIgnoreFailure
 
handleDeserializationFailure(String, boolean, String, byte[], Exception, Headers) - Method in interface io.smallrye.reactive.messaging.kafka.DeserializationFailureHandler
Handles a deserialization issue for a record's key.
HeaderExtractAdapter - Class in io.smallrye.reactive.messaging.kafka.tracing
 
HeaderExtractAdapter() - Constructor for class io.smallrye.reactive.messaging.kafka.tracing.HeaderExtractAdapter
 
HeaderInjectAdapter - Class in io.smallrye.reactive.messaging.kafka.tracing
 
HeaderInjectAdapter() - Constructor for class io.smallrye.reactive.messaging.kafka.tracing.HeaderInjectAdapter
 

I

illegalArgumentInvalidCommitStrategy(String) - Method in interface io.smallrye.reactive.messaging.kafka.i18n.KafkaExceptions
 
illegalArgumentInvalidCommitStrategy(String) - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaExceptions_$bundle
 
illegalArgumentInvalidCommitStrategy$str() - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaExceptions_$bundle
 
illegalArgumentInvalidFailureStrategy(String) - Method in interface io.smallrye.reactive.messaging.kafka.i18n.KafkaExceptions
 
illegalArgumentInvalidFailureStrategy(String) - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaExceptions_$bundle
 
illegalArgumentInvalidFailureStrategy$str() - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaExceptions_$bundle
 
illegalArgumentNoMetadata(Class) - Method in interface io.smallrye.reactive.messaging.kafka.i18n.KafkaExceptions
 
illegalArgumentNoMetadata(Class) - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaExceptions_$bundle
 
illegalArgumentNoMetadata$str() - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaExceptions_$bundle
 
illegalArgumentUnknownCommitStrategy(String) - Method in interface io.smallrye.reactive.messaging.kafka.i18n.KafkaExceptions
 
illegalArgumentUnknownCommitStrategy(String) - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaExceptions_$bundle
 
illegalArgumentUnknownCommitStrategy$str() - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaExceptions_$bundle
 
illegalArgumentUnknownFailureStrategy(String) - Method in interface io.smallrye.reactive.messaging.kafka.i18n.KafkaExceptions
 
illegalArgumentUnknownFailureStrategy(String) - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaExceptions_$bundle
 
illegalArgumentUnknownFailureStrategy$str() - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaExceptions_$bundle
 
illegalStateConsumeWithoutBackPressure() - Method in interface io.smallrye.reactive.messaging.kafka.i18n.KafkaExceptions
 
illegalStateConsumeWithoutBackPressure() - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaExceptions_$bundle
 
illegalStateConsumeWithoutBackPressure$str() - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaExceptions_$bundle
 
illegalStateOnlyOneSubscriber() - Method in interface io.smallrye.reactive.messaging.kafka.i18n.KafkaExceptions
 
illegalStateOnlyOneSubscriber() - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaExceptions_$bundle
 
illegalStateOnlyOneSubscriber$str() - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaExceptions_$bundle
 
IncomingKafkaCloudEventMetadata<K,T> - Interface in io.smallrye.reactive.messaging.kafka
Addition "extension" attribute specific to incoming Kafka record
IncomingKafkaRecord<K,T> - Class in io.smallrye.reactive.messaging.kafka
 
IncomingKafkaRecord(KafkaConsumerRecord<K, T>, KafkaCommitHandler, KafkaFailureHandler, boolean, boolean) - Constructor for class io.smallrye.reactive.messaging.kafka.IncomingKafkaRecord
 
IncomingKafkaRecordMetadata<K,T> - Class in io.smallrye.reactive.messaging.kafka
 
IncomingKafkaRecordMetadata(KafkaConsumerRecord<K, T>) - Constructor for class io.smallrye.reactive.messaging.kafka.IncomingKafkaRecordMetadata
 
incomingTrace(IncomingKafkaRecord<K, V>) - Method in class io.smallrye.reactive.messaging.kafka.impl.KafkaSource
 
inject(KafkaConsumer<?, ?>, ConsumerRebalanceListener) - Static method in class io.smallrye.reactive.messaging.kafka.impl.RebalanceListeners
HACK - inject the listener using reflection to replace the one set by vert.x
injectTracingMetadata(TracingMetadata) - Method in class io.smallrye.reactive.messaging.kafka.IncomingKafkaRecord
 
INSTANCE - Static variable in class io.smallrye.reactive.messaging.kafka.i18n.KafkaExceptions_$bundle
 
INSTANCE - Static variable in class io.smallrye.reactive.messaging.kafka.i18n.KafkaMessages_$bundle
 
invalidValueSerializerForStructuredCloudEvent(String) - Method in interface io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging
 
invalidValueSerializerForStructuredCloudEvent(String) - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging_$logger
 
invalidValueSerializerForStructuredCloudEvent$str() - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging_$logger
 
io.smallrye.reactive.messaging.kafka - package io.smallrye.reactive.messaging.kafka
 
io.smallrye.reactive.messaging.kafka.commit - package io.smallrye.reactive.messaging.kafka.commit
 
io.smallrye.reactive.messaging.kafka.converters - package io.smallrye.reactive.messaging.kafka.converters
 
io.smallrye.reactive.messaging.kafka.fault - package io.smallrye.reactive.messaging.kafka.fault
 
io.smallrye.reactive.messaging.kafka.i18n - package io.smallrye.reactive.messaging.kafka.i18n
 
io.smallrye.reactive.messaging.kafka.impl - package io.smallrye.reactive.messaging.kafka.impl
 
io.smallrye.reactive.messaging.kafka.impl.ce - package io.smallrye.reactive.messaging.kafka.impl.ce
 
io.smallrye.reactive.messaging.kafka.tracing - package io.smallrye.reactive.messaging.kafka.tracing
 
isAlive(HealthReport.HealthReportBuilder) - Method in class io.smallrye.reactive.messaging.kafka.impl.KafkaSink
 
isAlive(HealthReport.HealthReportBuilder) - Method in class io.smallrye.reactive.messaging.kafka.impl.KafkaSource
 
isReady(HealthReport.HealthReportBuilder) - Method in class io.smallrye.reactive.messaging.kafka.impl.KafkaSink
 
isReady(HealthReport.HealthReportBuilder) - Method in class io.smallrye.reactive.messaging.kafka.impl.KafkaSource
 

J

JsonHelper - Class in io.smallrye.reactive.messaging.kafka.impl
Be aware that this class is kafka specific.
JsonHelper() - Constructor for class io.smallrye.reactive.messaging.kafka.impl.JsonHelper
 

K

KAFKA_HEADER_CONTENT_TYPE - Static variable in class io.smallrye.reactive.messaging.kafka.impl.ce.KafkaCloudEventHelper
 
KAFKA_HEADER_FOR_CONTENT_TYPE - Static variable in class io.smallrye.reactive.messaging.kafka.impl.ce.KafkaCloudEventHelper
 
KAFKA_HEADER_FOR_ID - Static variable in class io.smallrye.reactive.messaging.kafka.impl.ce.KafkaCloudEventHelper
 
KAFKA_HEADER_FOR_SCHEMA - Static variable in class io.smallrye.reactive.messaging.kafka.impl.ce.KafkaCloudEventHelper
 
KAFKA_HEADER_FOR_SOURCE - Static variable in class io.smallrye.reactive.messaging.kafka.impl.ce.KafkaCloudEventHelper
 
KAFKA_HEADER_FOR_SPEC_VERSION - Static variable in class io.smallrye.reactive.messaging.kafka.impl.ce.KafkaCloudEventHelper
 
KAFKA_HEADER_FOR_SUBJECT - Static variable in class io.smallrye.reactive.messaging.kafka.impl.ce.KafkaCloudEventHelper
 
KAFKA_HEADER_FOR_TIME - Static variable in class io.smallrye.reactive.messaging.kafka.impl.ce.KafkaCloudEventHelper
 
KAFKA_HEADER_FOR_TYPE - Static variable in class io.smallrye.reactive.messaging.kafka.impl.ce.KafkaCloudEventHelper
 
KafkaAdminHelper - Class in io.smallrye.reactive.messaging.kafka.impl
 
KafkaCDIEvents - Class in io.smallrye.reactive.messaging.kafka
 
KafkaCDIEvents() - Constructor for class io.smallrye.reactive.messaging.kafka.KafkaCDIEvents
 
KafkaCloudEventHelper - Class in io.smallrye.reactive.messaging.kafka.impl.ce
 
KafkaCloudEventHelper.CloudEventMode - Enum in io.smallrye.reactive.messaging.kafka.impl.ce
 
KafkaCommitHandler - Interface in io.smallrye.reactive.messaging.kafka.commit
 
KafkaCommitHandler.Strategy - Enum in io.smallrye.reactive.messaging.kafka.commit
 
KafkaConnector - Class in io.smallrye.reactive.messaging.kafka
 
KafkaConnector() - Constructor for class io.smallrye.reactive.messaging.kafka.KafkaConnector
 
KafkaConnectorCommonConfiguration - Class in io.smallrye.reactive.messaging.kafka
Extracts the common configuration for the smallrye-kafka connector.
KafkaConnectorCommonConfiguration(Config) - Constructor for class io.smallrye.reactive.messaging.kafka.KafkaConnectorCommonConfiguration
Creates a new KafkaConnectorCommonConfiguration.
KafkaConnectorIncomingConfiguration - Class in io.smallrye.reactive.messaging.kafka
Extract the incoming configuration for the smallrye-kafka connector.
KafkaConnectorIncomingConfiguration(Config) - Constructor for class io.smallrye.reactive.messaging.kafka.KafkaConnectorIncomingConfiguration
Creates a new KafkaConnectorIncomingConfiguration.
KafkaConnectorOutgoingConfiguration - Class in io.smallrye.reactive.messaging.kafka
Extract the outgoing configuration for the smallrye-kafka connector.
KafkaConnectorOutgoingConfiguration(Config) - Constructor for class io.smallrye.reactive.messaging.kafka.KafkaConnectorOutgoingConfiguration
Creates a new KafkaConnectorOutgoingConfiguration.
KafkaConsumerRebalanceListener - Interface in io.smallrye.reactive.messaging.kafka
When implemented by a managed bean annotated with Named and configured against an inbound connector will be applied as a consumer re-balance listener to that inbound connector's consumer.
KafkaDeadLetterQueue - Class in io.smallrye.reactive.messaging.kafka.fault
 
KafkaDeadLetterQueue(String, String, KafkaProducer, KafkaSource<?, ?>) - Constructor for class io.smallrye.reactive.messaging.kafka.fault.KafkaDeadLetterQueue
 
KafkaExceptions - Interface in io.smallrye.reactive.messaging.kafka.i18n
Exceptions for Kafka Connector Assigned ID range is 18000-18099
KafkaExceptions_$bundle - Class in io.smallrye.reactive.messaging.kafka.i18n
Warning this class consists of generated code.
KafkaExceptions_$bundle() - Constructor for class io.smallrye.reactive.messaging.kafka.i18n.KafkaExceptions_$bundle
 
KafkaFailStop - Class in io.smallrye.reactive.messaging.kafka.fault
 
KafkaFailStop(String, KafkaSource<?, ?>) - Constructor for class io.smallrye.reactive.messaging.kafka.fault.KafkaFailStop
 
KafkaFailureHandler - Interface in io.smallrye.reactive.messaging.kafka.fault
 
KafkaFailureHandler.Strategy - Enum in io.smallrye.reactive.messaging.kafka.fault
 
KafkaIgnoreCommit - Class in io.smallrye.reactive.messaging.kafka.commit
Ignores an ACK and does not commit any offsets.
KafkaIgnoreCommit() - Constructor for class io.smallrye.reactive.messaging.kafka.commit.KafkaIgnoreCommit
 
KafkaIgnoreFailure - Class in io.smallrye.reactive.messaging.kafka.fault
 
KafkaIgnoreFailure(String) - Constructor for class io.smallrye.reactive.messaging.kafka.fault.KafkaIgnoreFailure
 
KafkaLatestCommit - Class in io.smallrye.reactive.messaging.kafka.commit
Will commit the record offset received by the Kafka consumer (if higher than the previously committed offset).
KafkaLatestCommit(Vertx, KafkaConnectorIncomingConfiguration, KafkaConsumer<?, ?>) - Constructor for class io.smallrye.reactive.messaging.kafka.commit.KafkaLatestCommit
 
KafkaLogging - Interface in io.smallrye.reactive.messaging.kafka.i18n
Logging for Kafka Connector Assigned ID range is 18200-18299
KafkaLogging_$logger - Class in io.smallrye.reactive.messaging.kafka.i18n
Warning this class consists of generated code.
KafkaLogging_$logger(Logger) - Constructor for class io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging_$logger
 
KafkaMessage<K,T> - Interface in io.smallrye.reactive.messaging.kafka
Deprecated.
KafkaMessageMetadata<K> - Interface in io.smallrye.reactive.messaging.kafka
 
KafkaMessages - Interface in io.smallrye.reactive.messaging.kafka.i18n
Messages for Kafka Connector Assigned ID range is 18100-18199
KafkaMessages_$bundle - Class in io.smallrye.reactive.messaging.kafka.i18n
Warning this class consists of generated code.
KafkaMessages_$bundle() - Constructor for class io.smallrye.reactive.messaging.kafka.i18n.KafkaMessages_$bundle
 
KafkaRecord<K,T> - Interface in io.smallrye.reactive.messaging.kafka
 
KafkaSink - Class in io.smallrye.reactive.messaging.kafka.impl
 
KafkaSink(Vertx, KafkaConnectorOutgoingConfiguration, KafkaCDIEvents) - Constructor for class io.smallrye.reactive.messaging.kafka.impl.KafkaSink
 
KafkaSource<K,V> - Class in io.smallrye.reactive.messaging.kafka.impl
 
KafkaSource(Vertx, String, KafkaConnectorIncomingConfiguration, Instance<KafkaConsumerRebalanceListener>, KafkaCDIEvents, Instance<DeserializationFailureHandler<?>>, int) - Constructor for class io.smallrye.reactive.messaging.kafka.impl.KafkaSource
 
KafkaThrottledLatestProcessedCommit - Class in io.smallrye.reactive.messaging.kafka.commit
Will keep track of received messages and commit to the next offset after the latest ACKed message in sequence.
KafkaThrottledLatestProcessedCommit.TooManyMessagesWithoutAckException - Class in io.smallrye.reactive.messaging.kafka.commit
 
key() - Method in class io.smallrye.reactive.messaging.kafka.Record
 
keyDeserializerOmitted() - Method in interface io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging
 
keyDeserializerOmitted() - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging_$logger
 
keyDeserializerOmitted$str() - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging_$logger
 

L

loadingConsumerRebalanceListenerFromConfiguredName(String) - Method in interface io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging
 
loadingConsumerRebalanceListenerFromConfiguredName(String) - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging_$logger
 
loadingConsumerRebalanceListenerFromConfiguredName$str() - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging_$logger
 
loadingConsumerRebalanceListenerFromGroupId(String) - Method in interface io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging
 
loadingConsumerRebalanceListenerFromGroupId(String) - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging_$logger
 
loadingConsumerRebalanceListenerFromGroupId$str() - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging_$logger
 
log - Static variable in interface io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging
 

M

messageAckedForRevokedTopicPartition(long, String, String) - Method in interface io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging
 
messageAckedForRevokedTopicPartition(long, String, String) - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging_$logger
 
messageAckedForRevokedTopicPartition$str() - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging_$logger
 
messageNackedDeadLetter(String, String) - Method in interface io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging
 
messageNackedDeadLetter(String, String) - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging_$logger
 
messageNackedDeadLetter$str() - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging_$logger
 
messageNackedFailStop(String) - Method in interface io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging
 
messageNackedFailStop(String) - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging_$logger
 
messageNackedFailStop$str() - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging_$logger
 
messageNackedFullIgnored(Throwable) - Method in interface io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging
 
messageNackedFullIgnored(Throwable) - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging_$logger
 
messageNackedFullIgnored$str() - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging_$logger
 
messageNackedIgnore(String, String) - Method in interface io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging
 
messageNackedIgnore(String, String) - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging_$logger
 
messageNackedIgnore$str() - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging_$logger
 
missingValueDeserializer(String, String) - Method in interface io.smallrye.reactive.messaging.kafka.i18n.KafkaExceptions
 
missingValueDeserializer(String, String) - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaExceptions_$bundle
 
missingValueDeserializer$str() - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaExceptions_$bundle
 
msg - Static variable in interface io.smallrye.reactive.messaging.kafka.i18n.KafkaMessages
 

N

nack(Throwable) - Method in class io.smallrye.reactive.messaging.kafka.IncomingKafkaRecord
 
nackingMessage(Message, String, Throwable) - Method in interface io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging
 
nackingMessage(Message, String, Throwable) - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging_$logger
 
nackingMessage$str() - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging_$logger
 
noGroupId(String) - Method in interface io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging
 
noGroupId(String) - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging_$logger
 
noGroupId$str() - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging_$logger
 

O

of(K, T) - Static method in interface io.smallrye.reactive.messaging.kafka.KafkaMessage
Deprecated.
Creates a new outgoing kafka message.
of(String, K, T) - Static method in interface io.smallrye.reactive.messaging.kafka.KafkaMessage
Deprecated.
Creates a new outgoing kafka message.
of(String, K, T, Instant, int) - Static method in interface io.smallrye.reactive.messaging.kafka.KafkaMessage
Deprecated.
Creates a new outgoing kafka message.
of(K, T) - Static method in interface io.smallrye.reactive.messaging.kafka.KafkaRecord
Creates a new outgoing Kafka record.
of(String, K, T) - Static method in interface io.smallrye.reactive.messaging.kafka.KafkaRecord
Creates a new outgoing Kafka record.
of(String, K, T, Instant, int) - Static method in interface io.smallrye.reactive.messaging.kafka.KafkaRecord
Creates a new outgoing Kafka record.
of(K, V) - Static method in class io.smallrye.reactive.messaging.kafka.Record
Creates a new record.
onPartitionsAssigned(Consumer<?, ?>, Collection<TopicPartition>) - Method in interface io.smallrye.reactive.messaging.kafka.KafkaConsumerRebalanceListener
A callback method the user can implement to provide handling of customized offsets on completion of a successful partition re-assignment.
onPartitionsLost(Consumer<?, ?>, Collection<TopicPartition>) - Method in interface io.smallrye.reactive.messaging.kafka.KafkaConsumerRebalanceListener
A callback method you can implement to provide handling of cleaning up resources for partitions that have already been reassigned to other consumers.
onPartitionsRevoked(Consumer<?, ?>, Collection<TopicPartition>) - Method in interface io.smallrye.reactive.messaging.kafka.KafkaConsumerRebalanceListener
A callback method the user can implement to provide handling of offset commits to a customized store.
OutgoingKafkaRecord<K,T> - Class in io.smallrye.reactive.messaging.kafka
 
OutgoingKafkaRecord(String, K, T, Instant, int, Headers, Supplier<CompletionStage<Void>>, Function<Throwable, CompletionStage<Void>>, Metadata) - Constructor for class io.smallrye.reactive.messaging.kafka.OutgoingKafkaRecord
 
OutgoingKafkaRecordMetadata<K> - Class in io.smallrye.reactive.messaging.kafka
 
OutgoingKafkaRecordMetadata(String, K, int, Instant, Headers) - Constructor for class io.smallrye.reactive.messaging.kafka.OutgoingKafkaRecordMetadata
 
OutgoingKafkaRecordMetadata.OutgoingKafkaRecordMetadataBuilder<K> - Class in io.smallrye.reactive.messaging.kafka
 
OutgoingKafkaRecordMetadataBuilder() - Constructor for class io.smallrye.reactive.messaging.kafka.OutgoingKafkaRecordMetadata.OutgoingKafkaRecordMetadataBuilder
 

P

partitionsAssigned(Collection<TopicPartition>) - Method in interface io.smallrye.reactive.messaging.kafka.commit.KafkaCommitHandler
 
partitionsAssigned(Collection<TopicPartition>) - Method in class io.smallrye.reactive.messaging.kafka.commit.KafkaThrottledLatestProcessedCommit
New partitions are assigned.
partitionsRevoked(Collection<TopicPartition>) - Method in interface io.smallrye.reactive.messaging.kafka.commit.KafkaCommitHandler
 
partitionsRevoked(Collection<TopicPartition>) - Method in class io.smallrye.reactive.messaging.kafka.commit.KafkaThrottledLatestProcessedCommit
Revoked partitions.
producer() - Method in class io.smallrye.reactive.messaging.kafka.KafkaCDIEvents
 

R

readResolve() - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaExceptions_$bundle
 
readResolve() - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaMessages_$bundle
 
RebalanceListeners - Class in io.smallrye.reactive.messaging.kafka.impl
 
RebalanceListeners() - Constructor for class io.smallrye.reactive.messaging.kafka.impl.RebalanceListeners
 
received(IncomingKafkaRecord<K, V>) - Method in interface io.smallrye.reactive.messaging.kafka.commit.KafkaCommitHandler
 
received(IncomingKafkaRecord<K, V>) - Method in class io.smallrye.reactive.messaging.kafka.commit.KafkaThrottledLatestProcessedCommit
Received a new record from Kafka.
receivedTooManyMessagesWithoutAcking(String, long, long) - Method in interface io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging
 
receivedTooManyMessagesWithoutAcking(String, long, long) - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging_$logger
 
receivedTooManyMessagesWithoutAcking$str() - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging_$logger
 
Record<K,V> - Class in io.smallrye.reactive.messaging.kafka
Represents a produced Kafka record, so a pair {key, value}.
RecordConverter - Class in io.smallrye.reactive.messaging.kafka.converters
Convert an incoming Kafka message into a Record.
RecordConverter() - Constructor for class io.smallrye.reactive.messaging.kafka.converters.RecordConverter
 
reEnablingConsumerForGroup(String) - Method in interface io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging
 
reEnablingConsumerForGroup(String) - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging_$logger
 
reEnablingConsumerForGroup$str() - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging_$logger
 
reportFailure(Throwable, boolean) - Method in class io.smallrye.reactive.messaging.kafka.impl.KafkaSource
 
RFC3339_DATE_FORMAT - Static variable in class io.smallrye.reactive.messaging.kafka.impl.ce.KafkaCloudEventHelper
 
runOnContext(Runnable) - Method in class io.smallrye.reactive.messaging.kafka.commit.ContextHolder
 
runOnContextAndAwait(Callable<T>) - Method in class io.smallrye.reactive.messaging.kafka.commit.ContextHolder
 

S

sendingMessageToTopic(Message, String) - Method in interface io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging
 
sendingMessageToTopic(Message, String) - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging_$logger
 
sendingMessageToTopic$str() - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging_$logger
 
set(Headers, String, String) - Method in class io.smallrye.reactive.messaging.kafka.tracing.HeaderInjectAdapter
 
setKafkaConsumerClientId(String) - Method in interface io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging
 
setKafkaConsumerClientId(String) - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging_$logger
 
setKafkaConsumerClientId$str() - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging_$logger
 
setKafkaProducerClientId(String) - Method in interface io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging
 
setKafkaProducerClientId(String) - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging_$logger
 
setKafkaProducerClientId$str() - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging_$logger
 
SETTER - Static variable in class io.smallrye.reactive.messaging.kafka.tracing.HeaderInjectAdapter
 
setThrottledCommitStrategyReceivedRecordMaxAge(String, long) - Method in interface io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging
 
setThrottledCommitStrategyReceivedRecordMaxAge(String, long) - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging_$logger
 
setThrottledCommitStrategyReceivedRecordMaxAge$str() - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging_$logger
 
settingCommitInterval(String, long) - Method in interface io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging
 
settingCommitInterval(String, long) - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging_$logger
 
settingCommitInterval$str() - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging_$logger
 
STRUCTURED_CONTENT_TYPE - Static variable in class io.smallrye.reactive.messaging.kafka.impl.ce.KafkaCloudEventHelper
 
successfullyToTopic(Message, String) - Method in interface io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging
 
successfullyToTopic(Message, String) - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging_$logger
 
successfullyToTopic$str() - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging_$logger
 

T

terminate() - Method in interface io.smallrye.reactive.messaging.kafka.commit.KafkaCommitHandler
 
terminate() - Method in class io.smallrye.reactive.messaging.kafka.commit.KafkaThrottledLatestProcessedCommit
 
terminate() - Method in class io.smallrye.reactive.messaging.kafka.fault.KafkaDeadLetterQueue
 
terminate() - Method in interface io.smallrye.reactive.messaging.kafka.fault.KafkaFailureHandler
 
terminate(Object) - Method in class io.smallrye.reactive.messaging.kafka.KafkaConnector
 
TooManyMessagesWithoutAckException(String, int, long) - Constructor for class io.smallrye.reactive.messaging.kafka.commit.KafkaThrottledLatestProcessedCommit.TooManyMessagesWithoutAckException
 
TRACER - Static variable in class io.smallrye.reactive.messaging.kafka.KafkaConnector
 

U

unableToCreateInstance(String, Throwable) - Method in interface io.smallrye.reactive.messaging.kafka.i18n.KafkaExceptions
 
unableToCreateInstance(String, Throwable) - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaExceptions_$bundle
 
unableToCreateInstance$str() - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaExceptions_$bundle
 
unableToDispatch(Throwable) - Method in interface io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging
 
unableToDispatch(Throwable) - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging_$logger
 
unableToDispatch$str() - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging_$logger
 
unableToExecuteConsumerAssignedRebalanceListener(String, Throwable) - Method in interface io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging
 
unableToExecuteConsumerAssignedRebalanceListener(String, Throwable) - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging_$logger
 
unableToExecuteConsumerAssignedRebalanceListener$str() - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging_$logger
 
unableToExecuteConsumerRevokedRebalanceListener(String, Throwable) - Method in interface io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging
 
unableToExecuteConsumerRevokedRebalanceListener(String, Throwable) - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging_$logger
 
unableToExecuteConsumerRevokedRebalanceListener$str() - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging_$logger
 
unableToFindDeserializationFailureHandler(String, String) - Method in interface io.smallrye.reactive.messaging.kafka.i18n.KafkaExceptions
 
unableToFindDeserializationFailureHandler(String, String, int) - Method in interface io.smallrye.reactive.messaging.kafka.i18n.KafkaExceptions
 
unableToFindDeserializationFailureHandler(String, String) - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaExceptions_$bundle
 
unableToFindDeserializationFailureHandler(String, String, int) - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaExceptions_$bundle
 
unableToFindDeserializationFailureHandler2$str() - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaExceptions_$bundle
 
unableToFindDeserializationFailureHandler3$str() - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaExceptions_$bundle
 
unableToFindRebalanceListener(String, String) - Method in interface io.smallrye.reactive.messaging.kafka.i18n.KafkaExceptions
 
unableToFindRebalanceListener(String, String, int) - Method in interface io.smallrye.reactive.messaging.kafka.i18n.KafkaExceptions
 
unableToFindRebalanceListener(String, String) - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaExceptions_$bundle
 
unableToFindRebalanceListener(String, String, int) - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaExceptions_$bundle
 
unableToFindRebalanceListener2$str() - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaExceptions_$bundle
 
unableToFindRebalanceListener3$str() - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaExceptions_$bundle
 
unableToReadRecord(Set<String>, Throwable) - Method in interface io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging
 
unableToReadRecord(Set<String>, Throwable) - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging_$logger
 
unableToReadRecord$str() - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging_$logger
 
unableToSendRecord(Throwable) - Method in interface io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging
 
unableToSendRecord(Throwable) - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging_$logger
 
unableToSendRecord$str() - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging_$logger
 
unableToWrite(String, String, Throwable) - Method in interface io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging
 
unableToWrite(String, Throwable) - Method in interface io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging
 
unableToWrite(String, String, Throwable) - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging_$logger
 
unableToWrite(String, Throwable) - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging_$logger
 
unableToWrite1$str() - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging_$logger
 
unableToWrite2$str() - Method in class io.smallrye.reactive.messaging.kafka.i18n.KafkaLogging_$logger
 

V

validate() - Method in class io.smallrye.reactive.messaging.kafka.KafkaConnectorCommonConfiguration
 
validate() - Method in class io.smallrye.reactive.messaging.kafka.KafkaConnectorIncomingConfiguration
 
validate() - Method in class io.smallrye.reactive.messaging.kafka.KafkaConnectorOutgoingConfiguration
 
value() - Method in class io.smallrye.reactive.messaging.kafka.Record
 
valueOf(String) - Static method in enum io.smallrye.reactive.messaging.kafka.commit.KafkaCommitHandler.Strategy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.smallrye.reactive.messaging.kafka.fault.KafkaFailureHandler.Strategy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.smallrye.reactive.messaging.kafka.impl.ce.KafkaCloudEventHelper.CloudEventMode
Returns the enum constant of this type with the specified name.
values() - Static method in enum io.smallrye.reactive.messaging.kafka.commit.KafkaCommitHandler.Strategy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.smallrye.reactive.messaging.kafka.fault.KafkaFailureHandler.Strategy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.smallrye.reactive.messaging.kafka.impl.ce.KafkaCloudEventHelper.CloudEventMode
Returns an array containing the constants of this enum type, in the order they are declared.
vertx - Variable in class io.smallrye.reactive.messaging.kafka.commit.ContextHolder
 

W

with(String, K, T) - Method in class io.smallrye.reactive.messaging.kafka.OutgoingKafkaRecord
 
with(String, T) - Method in class io.smallrye.reactive.messaging.kafka.OutgoingKafkaRecord
 
with(String, K, T, Instant, int) - Method in class io.smallrye.reactive.messaging.kafka.OutgoingKafkaRecord
 
withAck(Supplier<CompletionStage<Void>>) - Method in class io.smallrye.reactive.messaging.kafka.OutgoingKafkaRecord
 
withHeader(String, byte[]) - Method in class io.smallrye.reactive.messaging.kafka.OutgoingKafkaRecord
Creates a new outgoing Kafka Message with a header added to the header list.
withHeader(String, String) - Method in class io.smallrye.reactive.messaging.kafka.OutgoingKafkaRecord
Creates a new outgoing Kafka Message with a header added to the header list.
withHeader(String, String, Charset) - Method in class io.smallrye.reactive.messaging.kafka.OutgoingKafkaRecord
Creates a new outgoing Kafka Message with a header added to the header list.
withHeaders(Headers) - Method in class io.smallrye.reactive.messaging.kafka.OutgoingKafkaRecordMetadata.OutgoingKafkaRecordMetadataBuilder
 
withHeaders(List<RecordHeader>) - Method in class io.smallrye.reactive.messaging.kafka.OutgoingKafkaRecordMetadata.OutgoingKafkaRecordMetadataBuilder
 
withKey(K) - Method in class io.smallrye.reactive.messaging.kafka.OutgoingKafkaRecordMetadata.OutgoingKafkaRecordMetadataBuilder
 
withKey(T) - Method in class io.smallrye.reactive.messaging.kafka.Record
Creates a new instance of Record with given key and the value from the current record.
withMetadata(Iterable<Object>) - Method in class io.smallrye.reactive.messaging.kafka.OutgoingKafkaRecord
 
withMetadata(Metadata) - Method in class io.smallrye.reactive.messaging.kafka.OutgoingKafkaRecord
 
withNack(Function<Throwable, CompletionStage<Void>>) - Method in class io.smallrye.reactive.messaging.kafka.OutgoingKafkaRecord
 
withPartition(int) - Method in class io.smallrye.reactive.messaging.kafka.OutgoingKafkaRecordMetadata.OutgoingKafkaRecordMetadataBuilder
 
withPayload(P) - Method in class io.smallrye.reactive.messaging.kafka.OutgoingKafkaRecord
 
withTimestamp(Instant) - Method in class io.smallrye.reactive.messaging.kafka.OutgoingKafkaRecordMetadata.OutgoingKafkaRecordMetadataBuilder
 
withTopic(String) - Method in class io.smallrye.reactive.messaging.kafka.OutgoingKafkaRecordMetadata.OutgoingKafkaRecordMetadataBuilder
 
withValue(T) - Method in class io.smallrye.reactive.messaging.kafka.Record
Creates a new instance of Record with the key from the current record and the new value.
A B C D E F G H I J K L M N O P R S T U V W 
Skip navigation links

Copyright © 2018–2020 SmallRye. All rights reserved.