All Classes Interface Summary Class Summary Enum Summary Exception Summary Annotation Types Summary
Class |
Description |
AbstractEmitter<T> |
|
AbstractMediator |
|
Acknowledgment |
Configure the acknowledgement policy for the given @Incoming .
|
Acknowledgment.Strategy |
|
AmqpAccept |
|
AmqpClientHelper |
|
AmqpCloudEventHelper |
|
AmqpCloudEventHelper.CloudEventMode |
|
AmqpConfiguration |
|
AmqpConnector |
|
AmqpConnectorCommonConfiguration |
Extracts the common configuration for the smallrye-amqp connector.
|
AmqpConnectorIncomingConfiguration |
Extract the incoming configuration for the smallrye-amqp connector.
|
AmqpConnectorOutgoingConfiguration |
Extract the outgoing configuration for the smallrye-amqp connector.
|
AmqpCreditBasedSender |
|
AMQPExceptions |
Exceptions for AMQP Connector
Assigned ID range is 16000-16099
|
AMQPExceptions_$bundle |
Warning this class consists of generated code.
|
AmqpFailStop |
|
AmqpFailureHandler |
|
AmqpFailureHandler.Strategy |
|
AMQPLogging |
Logging for AMQP Connector
Assigned ID range is 16200-16299
|
AMQPLogging_$logger |
Warning this class consists of generated code.
|
AmqpMessage<T> |
|
AmqpMessageBuilder<T> |
Deprecated.
|
AmqpMessageConverter |
|
AMQPMessages |
Messages for AMQP Connector
Assigned ID range is 16100-16199
|
AMQPMessages_$bundle |
Warning this class consists of generated code.
|
AmqpModifiedFailed |
This nack strategy marking the message as modified and set the delivery-failed attribute to true .
|
AmqpModifiedFailedAndUndeliverableHere |
This nack strategy marking the message as modified and set the delivery-failed attribute to true ,
as well as the undeliverable-here flag to true .
|
AmqpReject |
|
AmqpRelease |
|
BaseCloudEventMetadata<T> |
|
BaseHealth |
|
BeanUsingAnEmitter |
|
Blocking |
Identifies that a particular method performs blocking operations,
and as such should be executed on separate worker.
|
Broadcast |
Configure if the annotated publisher should dispatch the messages to several subscribers.
|
BroadcastHelper |
|
CamelConnector |
|
CamelConnectorCommonConfiguration |
Extracts the common configuration for the smallrye-camel connector.
|
CamelConnectorIncomingConfiguration |
Extract the incoming configuration for the smallrye-camel connector.
|
CamelConnectorOutgoingConfiguration |
Extract the outgoing configuration for the smallrye-camel connector.
|
CamelExceptions |
Exceptions for Camel Connector
Assigned ID range is 17600-17699
|
CamelExceptions_$bundle |
Warning this class consists of generated code.
|
CamelFailStop |
|
CamelFailureHandler |
|
CamelFailureHandler.Strategy |
|
CamelIgnoreFailure |
|
CamelLogging |
Logging for Camel Connector
Assigned ID range is 17800-17899
|
CamelLogging_$logger |
Warning this class consists of generated code.
|
CamelMessage<T> |
|
CamelMessages |
Messages for Camel Connector
Assigned ID range is 17700-17799
|
CamelMessages_$bundle |
Warning this class consists of generated code.
|
Channel |
Deprecated.
|
Channel |
This qualifier indicates which channel should be injected / populated.
|
ChannelConfiguration |
|
ChannelProducer |
This component computes the right object to be injected into injection point using Channel and the
deprecated Channel .
|
ChannelRegistar |
|
ChannelRegistry |
|
ClassUtils |
Allows checking if a class can be assigned to a variable from another class.
|
ClassWriter |
|
Clients |
|
Clients.ClientHolder |
|
CloudEventMetadata<T> |
Represents Cloud Event metadata
See https://github.com/cloudevents/spec/blob/v1.0/spec.md.
|
CommonConfigurationClassWriter |
Generates the parent class used by the incoming and outgoing configuration classes.
|
ConfigHelper |
|
ConfigurationClassWriter |
|
ConfigurationCleaner |
|
ConfigurationDocWriter |
|
ConfiguredChannelFactory |
Look for stream factories and get instances.
|
ConnectionHolder |
|
ConnectionHolder |
|
Connector |
Qualifier used on connector implementations to indicate the associated underlying transport.
|
ConnectorAttribute |
Annotation used to declare an attribute on the connector.
|
ConnectorAttribute.Direction |
|
ConnectorAttributeProcessor |
|
ConnectorAttributes |
|
ConnectorConfig |
Implementation of config used to configured the different messaging provider / connector.
|
ConnectorFactories |
|
ConnectorFactory |
|
ConnectorLiteral |
Supports inline instantiation of the Connector qualifier.
|
ConstantReconnectDelayOptions |
|
ConsumerRecordConverter |
Convert an incoming Kafka message into a ConsumerRecord .
|
ConsumerRecordsConverter |
Convert an incoming Kafka batch message into a ConsumerRecords .
|
ContextHolder |
A class holding a vert.x context to make sure methods are always run from the same one.
|
ConverterUtils |
|
CycleException |
|
DefaultCloudEventMetadataBuilder<T> |
|
DefaultIncomingCloudEventMetadata<T> |
|
DefaultIncomingKafkaCloudEventMetadata<K,T> |
|
DefaultMediatorConfiguration |
|
DefaultMediatorConfiguration.AlwaysInvalidIndexGenericTypeAssignable |
|
DefaultMediatorConfiguration.MethodParamGenericTypeAssignable |
|
DefaultMediatorConfiguration.ReturnTypeGenericTypeAssignable |
|
DefaultOutgoingCloudEventMetadata<T> |
|
DeserializationFailureHandler<T> |
Bean invoked on Kafka deserialization to implement custom failure handling.
|
DeserializerWrapper<T> |
Wraps a delegate deserializer to handle config and deserialization failures.
|
Emitter<T> |
Deprecated.
|
Emitter<T> |
Interface used to feed a channel from an imperative piece of code.
|
EmitterConfiguration |
Emitter configuration.
|
EmitterImpl<T> |
Implementation of the emitter pattern.
|
ExecutionHolder |
Provides common runtime services to connectors, such as a Vertx instance,
to avoid duplicating the creation and cleanup of shared components across connectors.
|
ExponentialBackoffDelayOptions |
|
Graph |
|
HeaderExtractAdapter |
|
HeaderExtractAdapter |
|
HeaderInjectAdapter |
|
HeaderInjectAdapter |
|
HeadersMapExtractAdapter |
A TextMapGetter that is sourced from a string-keyed Map.
|
HealthCenter |
Component responsible to compute the current state of the reactive messaging application.
|
HealthCenter.ReportedFailure |
|
HealthChecks |
|
HealthReport |
Represent an health status and its set of attached data.
|
HealthReport.ChannelInfo |
Structure storing the health detail of a specific channel.
|
HealthReport.HealthReportBuilder |
|
HealthReporter |
Interface implemented by connector to participate to the health data collection.
|
IgnoringSubscriber |
|
ImmutableJmsProperties |
|
InboundConnector |
SPI used to implement a connector managing a source of messages for a specific transport.
|
Incoming |
Used to signify a subscriber to incoming messages.
|
IncomingAmqpMetadata |
|
IncomingCloudEventMetadata<T> |
Represents the Cloud Event metadata from an incoming message.
|
IncomingConnectorFactory |
SPI used to implement a connector managing a source of messages for a specific transport.
|
IncomingExchangeMetadata |
|
IncomingJmsMessage<T> |
|
IncomingJmsMessageMetadata |
|
IncomingKafkaCloudEventMetadata<K,T> |
Addition "extension" attribute specific to incoming Kafka record
|
IncomingKafkaRecord<K,T> |
|
IncomingKafkaRecordBatch<K,T> |
|
IncomingKafkaRecordBatchMetadata<K,T> |
Contains information about the batch of messages received from a channel backed by Kafka.
|
IncomingKafkaRecordMetadata<K,T> |
Contains information about messages received from a channel backed by Kafka.
|
IncomingKafkaRecordMetadata<K,T> |
Deprecated.
|
IncomingRabbitMQMessage<T> |
An implementation of Message suitable for incoming RabbitMQ messages.
|
IncomingRabbitMQMetadata |
Holds metadata from an incoming RabbitMQ message.
|
Incomings |
This class is used to allow multiple Incoming declarations.
|
InMemoryConnector |
An implementation of connector used for testing applications without having to use external broker.
|
InMemoryExceptions |
Exceptions for In-memory Connector
Assigned ID range is 18300-18399
|
InMemoryExceptions_$bundle |
Warning this class consists of generated code.
|
InMemoryLogging |
Logging for In-memory Connector
Assigned ID range is 18500-18599
|
InMemoryLogging_$logger |
Warning this class consists of generated code.
|
InMemoryMessages |
Messages for In-memory Connector
Assigned ID range is 18400-18499
|
InMemoryMessages_$bundle |
Warning this class consists of generated code.
|
InMemorySink<T> |
Allows interacting with an in-memory sink.
|
InMemorySource<T> |
Allows interacting with an in-memory source.
|
InternalChannelRegistry |
|
Invoker |
|
JacksonMapping |
|
JmsConnector |
|
JmsConnectorCommonConfiguration |
Extracts the common configuration for the smallrye-jms connector.
|
JmsConnectorIncomingConfiguration |
Extract the incoming configuration for the smallrye-jms connector.
|
JmsConnectorOutgoingConfiguration |
Extract the outgoing configuration for the smallrye-jms connector.
|
JmsExceptions |
Exceptions for JMS Connector
Assigned ID range is 15600-15699
|
JmsExceptions_$bundle |
Warning this class consists of generated code.
|
JmsLogging |
Logging for JMS Connector
Assigned ID range is 15800-15899
|
JmsLogging_$logger |
Warning this class consists of generated code.
|
JmsMessageMetadata |
|
JmsMessages |
Messages for JMS Connector
Assigned ID range is 15700-15799
|
JmsMessages_$bundle |
Warning this class consists of generated code.
|
JmsProperties |
Structure handling JMS Message properties.
|
JmsPropertiesBuilder |
|
JmsPropertiesBuilder.OutgoingJmsProperties |
|
JmsPropertiesBuilder.Property<T> |
|
JmsTask |
|
JsonBMapping |
|
JsonHelper |
Be aware that this class is kafka specific.
|
JsonMapping |
Interface to abstract json serialization to/from string.
|
KafkaAdmin |
Internal interface for Kafka admin client.
|
KafkaAdminHelper |
|
KafkaCDIEvents |
|
KafkaClientService |
|
KafkaClientServiceImpl |
|
KafkaCloudEventHelper |
|
KafkaCloudEventHelper.CloudEventMode |
|
KafkaCommitHandler |
|
KafkaCommitHandler.Strategy |
|
KafkaConnector |
|
KafkaConnectorCommonConfiguration |
Extracts the common configuration for the smallrye-kafka connector.
|
KafkaConnectorIncomingConfiguration |
Extract the incoming configuration for the smallrye-kafka connector.
|
KafkaConnectorOutgoingConfiguration |
Extract the outgoing configuration for the smallrye-kafka connector.
|
KafkaConsumer<K,V> |
Kafka Consumer API.
|
KafkaConsumerRebalanceListener |
When implemented by a managed bean annotated with @Identifier
and configured against an inbound connector, it will be applied as a consumer rebalance listener
to that inbound connector's consumer.
|
KafkaDeadLetterQueue |
|
KafkaExceptions |
Exceptions for Kafka Connector
Assigned ID range is 18000-18099
|
KafkaExceptions_$bundle |
Warning this class consists of generated code.
|
KafkaFailStop |
|
KafkaFailureHandler |
|
KafkaFailureHandler.Strategy |
|
KafkaIgnoreCommit |
Ignores an ACK and does not commit any offsets.
|
KafkaIgnoreFailure |
|
KafkaLatestCommit |
Will commit the record offset received by the Kafka consumer (if higher than the previously committed offset).
|
KafkaLogging |
Logging for Kafka Connector
Assigned ID range is 18200-18299
|
KafkaLogging_$logger |
Warning this class consists of generated code.
|
KafkaMessage<K,T> |
Deprecated.
|
KafkaMessageMetadata<K> |
Common interface for
|
KafkaMessageMetadata<K> |
Deprecated.
|
KafkaMessages |
Messages for Kafka Connector
Assigned ID range is 18100-18199
|
KafkaMessages_$bundle |
Warning this class consists of generated code.
|
KafkaMetadataUtil |
|
KafkaPollingThread |
|
KafkaPriceConsumer |
|
KafkaPriceMessageConsumer |
|
KafkaPriceMessageProducer |
|
KafkaPriceProducer |
|
KafkaProducer<K,V> |
Kafka Producer API.
|
KafkaRecord<K,T> |
|
KafkaRecordBatch<K,T> |
Represents a batch of Kafka records received by polling the KafkaConsumer
This type extends the Message<List<T>> where T is the type of records' payloads.
|
KafkaRecordBatchStream<K,V> |
|
KafkaRecordStream<K,V> |
|
KafkaRecordStreamSubscription<K,V,T> |
|
KafkaSendingThread |
|
KafkaSink |
|
KafkaSinkHealth |
|
KafkaSource<K,V> |
|
KafkaSourceHealth |
|
KafkaThrottledLatestProcessedCommit |
Will keep track of received messages and commit to the next offset after the latest
ACKed message in sequence.
|
KafkaThrottledLatestProcessedCommit.TooManyMessagesWithoutAckException |
|
LegacyEmitterImpl<T> |
Implementation of the old (legacy) Emitter interface.
|
Main |
|
MapBasedConfig |
An implementation of Config based on a simple Map .
|
MediatorConfiguration |
|
MediatorConfiguration.Consumption |
|
MediatorConfiguration.Production |
|
MediatorConfigurationSupport |
|
MediatorConfigurationSupport.GenericTypeAssignable |
|
MediatorConfigurationSupport.GenericTypeAssignable.Result |
|
MediatorConfigurationSupport.ValidationOutput |
|
MediatorFactory |
|
MediatorManager |
Class responsible for creating mediators instances and starting the management.
|
Merge |
Temporary annotation - must be copied to spec.
|
Merge.Mode |
|
Message<T> |
A message envelope.
|
MessageConverter |
Converter transforming Message<A> into Message<B> .
|
MessageConverter.IdentityConverter |
|
Metadata |
Message metadata containers.
|
MetricDecorator |
|
MicrometerDecorator |
|
MqttClientSession |
An MQTT client session.
|
MqttClientSessionImpl |
|
MqttClientSessionOptions |
|
MqttConnector |
|
MqttConnectorCommonConfiguration |
Extracts the common configuration for the smallrye-mqtt connector.
|
MqttConnectorIncomingConfiguration |
Extract the incoming configuration for the smallrye-mqtt connector.
|
MqttConnectorOutgoingConfiguration |
Extract the outgoing configuration for the smallrye-mqtt connector.
|
MqttExceptions |
Exceptions for MQTT Connector
Assigned ID range is 17000-17099
|
MqttExceptions_$bundle |
Warning this class consists of generated code.
|
MqttFailStop |
|
MqttFailureHandler |
|
MqttFailureHandler.Strategy |
|
MqttHelpers |
|
MqttIgnoreFailure |
|
MqttLogging |
Logging for MQTT Connector
Assigned ID range is 17100-17199
|
MqttLogging_$logger |
Warning this class consists of generated code.
|
MqttMessage<T> |
|
MqttMessages |
Messaging for MQTT Connector
Assigned ID range is 17200-17299
|
MqttMessages_$bundle |
Warning this class consists of generated code.
|
MqttSink |
|
MqttSource |
|
MultiUtils |
|
MutinyEmitter<T> |
Interface used to feed a channel from an imperative piece of code.
|
MutinyEmitterImpl<T> |
|
NoStackTraceException |
An exception that does not capture the stack trace.
|
OnOverflow |
Deprecated.
|
OnOverflow |
Configures the back pressure policy on an injected Emitter :
|
OnOverflow.Strategy |
The back pressure strategy.
|
OnOverflow.Strategy |
The back pressure strategy.
|
OpenGraphException |
|
OutboundConnector |
SPI used to implement a connector managing a sink of messages for a specific transport.
|
Outgoing |
Used to signify a publisher of outgoing messages.
|
OutgoingAmqpMessage<T> |
|
OutgoingAmqpMetadata |
|
OutgoingAmqpMetadata.OutgoingAmqpMetadataBuilder |
|
OutgoingCloudEventMetadata<T> |
Represents the Cloud Event metadata for an outgoing message.
|
OutgoingCloudEventMetadataBuilder<T> |
|
OutgoingConnectorFactory |
SPI used to implement a connector managing a sink of messages for a specific transport.
|
OutgoingExchangeMetadata |
|
OutgoingJmsMessageMetadata |
|
OutgoingJmsMessageMetadata.OutgoingJmsMessageMetadataBuilder |
|
OutgoingKafkaRecord<K,T> |
|
OutgoingKafkaRecordMetadata<K> |
Contains information the user can set to influence how messages are sent via Kafka.
|
OutgoingKafkaRecordMetadata<K> |
Deprecated.
|
OutgoingKafkaRecordMetadata.OutgoingKafkaRecordMetadataBuilder<K> |
|
OutgoingKafkaRecordMetadata.OutgoingKafkaRecordMetadataBuilder<K> |
|
OutgoingRabbitMQMetadata |
Used to represent RabbitMQ metadata in on outgoing message.
|
OutgoingRabbitMQMetadata.Builder |
|
ProcessingException |
|
ProcessorMediator |
|
ProviderExceptions |
|
ProviderExceptions_$bundle |
Warning this class consists of generated code.
|
ProviderLogging |
|
ProviderLogging_$logger |
Warning this class consists of generated code.
|
ProviderMessages |
|
ProviderMessages_$bundle |
Warning this class consists of generated code.
|
PublisherDecorator |
SPI to allow extension of publishers (Multi) included in the final graph
|
PublisherMediator |
|
PubSubConfig |
|
PubSubConnector |
|
PubSubExceptions |
Exceptions for GCP Pub/Sub Connector
Assigned ID range is 14600-14699
|
PubSubExceptions_$bundle |
Warning this class consists of generated code.
|
PubSubLogging |
Logging for GCP Pub/Sub Connector
Assigned ID range is 14800-14899
|
PubSubLogging_$logger |
Warning this class consists of generated code.
|
PubSubManager |
|
PubSubMessage |
|
PubSubMessageReceiver |
|
PubSubMessages |
Messages for GCP Pub/Sub Connector
Assigned ID range is 14700-14799
|
PubSubMessages_$bundle |
Warning this class consists of generated code.
|
PubSubSource |
|
RabbitMQAccept |
|
RabbitMQAck |
|
RabbitMQAckHandler |
Implemented to provide message acknowledgement strategies.
|
RabbitMQAckHandler.Strategy |
|
RabbitMQAutoAck |
|
RabbitMQClientHelper |
|
RabbitMQConnector |
|
RabbitMQConnectorCommonConfiguration |
Extracts the common configuration for the smallrye-rabbitmq connector.
|
RabbitMQConnectorIncomingConfiguration |
Extract the incoming configuration for the smallrye-rabbitmq connector.
|
RabbitMQConnectorOutgoingConfiguration |
Extract the outgoing configuration for the smallrye-rabbitmq connector.
|
RabbitMQExceptions |
Defines a bundle of exception messages each with a unique id.
|
RabbitMQExceptions_$bundle |
Warning this class consists of generated code.
|
RabbitMQFailStop |
|
RabbitMQFailureHandler |
Implemented to provide message failure strategies.
|
RabbitMQFailureHandler.Strategy |
|
RabbitMQLogging |
|
RabbitMQLogging_$logger |
Warning this class consists of generated code.
|
RabbitMQMessageConverter |
|
RabbitMQMessageConverter.OutgoingRabbitMQMessage |
Represents an outgoing RabbitMQ message.
|
RabbitMQMessages |
Messages for RabbitMQ Connector
Assigned ID range is 16100-16199
|
RabbitMQMessages_$bundle |
Warning this class consists of generated code.
|
RabbitMQMessageSender |
An implementation of Processor and Subscription that is responsible for sending
RabbitMQ messages to an external broker.
|
RabbitMQReject |
|
ReactiveKafkaAdminClient |
|
ReactiveKafkaConsumer<K,V> |
|
ReactiveKafkaProducer<K,V> |
|
ReactiveMessagingExtension |
|
RebalanceListeners |
|
Receiver |
|
ReceivingMqttMessage |
|
ReconnectDelayOptions |
|
ReconnectDelayProvider |
|
Record<K,V> |
Represents a produced Kafka record, so a pair {key, value}.
|
RecordConverter |
Convert an incoming Kafka message into a Record .
|
RecordQueue<T> |
Stores the records coming from Kafka.
|
RequestedQoS |
The requested QoS level.
|
Sender |
|
SendingMqttMessage<T> |
|
SerializationFailureHandler<T> |
Bean invoked on Kafka serialization failure.
|
SerializerWrapper<T> |
|
SessionEvent |
|
SessionEventImpl |
An event of a session state change.
|
SessionState |
The state of the session.
|
Shape |
|
SmallRyeReactiveMessagingExtender |
|
SmallRyeReactiveMessagingLivenessCheck |
|
SmallRyeReactiveMessagingReadinessCheck |
|
SmallRyeReactiveMessagingStartupCheck |
|
StreamTransformerMediator |
|
SubscriberMediator |
|
SubscriberWrapper<I,T> |
|
SubscriptionEvent |
|
SubscriptionEventImpl |
An event of a subscription state change.
|
SubscriptionState |
The state of a subscription.
|
TooManyDownstreamCandidatesException |
|
TooManyUpstreamCandidatesException |
|
TracingMetadata |
|
TracingUtils |
Utility methods to manage spans for incoming and outgoing messages.
|
TypeUtils |
Utility methods focusing on type inspection, particularly with regard to
generics.
|
UnsatisfiedBroadcastException |
|
Validation |
|
WeavingException |
|
Wiring |
|
Wiring.Component |
|
WiringException |
|
WorkerPoolRegistry |
|
Wrap |
|