A B C D E F G H I J K L M N O P R S T U V W
All Classes All Packages
All Classes All Packages
All Classes All Packages
A
- AbstractMediator - Class in io.smallrye.reactive.messaging
- AbstractMediator(MediatorConfiguration) - Constructor for class io.smallrye.reactive.messaging.AbstractMediator
- accept(MultiEmitter<? super Message<?>>) - Method in class io.smallrye.reactive.messaging.gcp.pubsub.PubSubSource
- ack() - Method in class io.smallrye.reactive.messaging.amqp.AmqpMessage
- ack() - Method in class io.smallrye.reactive.messaging.amqp.OutgoingAmqpMessage
- ack() - Method in class io.smallrye.reactive.messaging.aws.sns.SnsMessage
- ack() - Method in class io.smallrye.reactive.messaging.eventbus.EventBusMessage
- ack() - Method in class io.smallrye.reactive.messaging.gcp.pubsub.PubSubMessage
- ack() - Method in class io.smallrye.reactive.messaging.http.HttpMessage
- ack() - Method in class io.smallrye.reactive.messaging.jms.IncomingJmsMessage
- ack() - Method in class io.smallrye.reactive.messaging.kafka.IncomingKafkaRecord
- ack() - Method in class io.smallrye.reactive.messaging.kafka.OutgoingKafkaRecord
- ack() - Method in class io.smallrye.reactive.messaging.mqtt.SendingMqttMessage
- ack() - Method in class io.smallrye.reactive.messaging.mqtt.server.MqttMessage
- ack() - Method in interface org.eclipse.microprofile.reactive.messaging.Message
-
Acknowledge this message.
- Acknowledgment - Annotation Type in org.eclipse.microprofile.reactive.messaging
-
Configure the acknowledgement policy for the given
@Incoming
. - Acknowledgment.Strategy - Enum in org.eclipse.microprofile.reactive.messaging
- acme - package acme
- add(int[], int) - Static method in class io.smallrye.reactive.messaging.helpers.TypeUtils
- addAnalyzed(Collection<? extends MediatorConfiguration>) - Method in class io.smallrye.reactive.messaging.extension.MediatorManager
- addMetadata(Object) - Method in interface org.eclipse.microprofile.reactive.messaging.Message
-
Creates a new instance of
Message
with the current metadata, plus the given one. - alias() - Method in annotation type io.smallrye.reactive.messaging.annotations.ConnectorAttribute
- AmqpConfiguration - Class in acme
- AmqpConfiguration() - Constructor for class acme.AmqpConfiguration
- AmqpConnector - Class in io.smallrye.reactive.messaging.amqp
- AmqpConnectorCommonConfiguration - Class in io.smallrye.reactive.messaging.amqp
-
Extracts the common configuration for the
smallrye-amqp
connector. - AmqpConnectorCommonConfiguration(Config) - Constructor for class io.smallrye.reactive.messaging.amqp.AmqpConnectorCommonConfiguration
-
Creates a new AmqpConnectorCommonConfiguration.
- AmqpConnectorIncomingConfiguration - Class in io.smallrye.reactive.messaging.amqp
-
Extract the incoming configuration for the
smallrye-amqp
connector. - AmqpConnectorIncomingConfiguration(Config) - Constructor for class io.smallrye.reactive.messaging.amqp.AmqpConnectorIncomingConfiguration
-
Creates a new AmqpConnectorIncomingConfiguration.
- AmqpConnectorOutgoingConfiguration - Class in io.smallrye.reactive.messaging.amqp
-
Extract the outgoing configuration for the
smallrye-amqp
connector. - AmqpConnectorOutgoingConfiguration(Config) - Constructor for class io.smallrye.reactive.messaging.amqp.AmqpConnectorOutgoingConfiguration
-
Creates a new AmqpConnectorOutgoingConfiguration.
- AmqpMessage<T> - Class in io.smallrye.reactive.messaging.amqp
- AmqpMessage(AmqpMessage) - Constructor for class io.smallrye.reactive.messaging.amqp.AmqpMessage
- AmqpMessage(AmqpMessage) - Constructor for class io.smallrye.reactive.messaging.amqp.AmqpMessage
- AmqpMessageBuilder<T> - Class in io.smallrye.reactive.messaging.amqp
- amqpMetadata - Variable in class io.smallrye.reactive.messaging.amqp.AmqpMessage
- analyze(Class<?>, Bean<T>) - Method in class io.smallrye.reactive.messaging.extension.MediatorManager
- analyze(AnnotatedType<T>, Bean<T>) - Method in class io.smallrye.reactive.messaging.extension.MediatorManager
- analyzeWorker(AnnotatedType<T>) - Method in class io.smallrye.reactive.messaging.connectors.WorkerPoolRegistry
- anOutgoingAmqpMetadata() - Static method in class io.smallrye.reactive.messaging.amqp.OutgoingAmqpMetadata.OutgoingAmqpMetadataBuilder
- APPLICATION_JSON - Static variable in class io.smallrye.reactive.messaging.amqp.AmqpMessage
- apply(Message) - Method in interface io.smallrye.reactive.messaging.jms.impl.JmsTask
- apply(Message) - Method in class io.smallrye.reactive.messaging.jms.JmsPropertiesBuilder.Property
- asJsonObject(Config) - Static method in class io.smallrye.reactive.messaging.http.JsonHelper
- asJsonObject(Config) - Static method in class io.smallrye.reactive.messaging.kafka.impl.JsonHelper
- Assignable - io.smallrye.reactive.messaging.MediatorConfigurationSupport.GenericTypeAssignable.Result
- awssns - package awssns
B
- BeanUsingAnEmitter - Class in acme
- BeanUsingAnEmitter - Class in awssns
- BeanUsingAnEmitter - Class in gcp.pubsub
- BeanUsingAnEmitter() - Constructor for class acme.BeanUsingAnEmitter
- BeanUsingAnEmitter() - Constructor for class awssns.BeanUsingAnEmitter
- BeanUsingAnEmitter() - Constructor for class gcp.pubsub.BeanUsingAnEmitter
- Blocking - Annotation Type in io.smallrye.reactive.messaging.annotations
-
Identifies that a particular method performs blocking operations, and as such should be executed on separate worker.
- Broadcast - Annotation Type in io.smallrye.reactive.messaging.annotations
-
Configure if the annotated publisher should dispatch the messages to several subscribers.
- BUFFER - io.smallrye.reactive.messaging.annotations.OnOverflow.Strategy
-
Deprecated.Buffers all values until the downstream consumes it.
- BUFFER - org.eclipse.microprofile.reactive.messaging.OnOverflow.Strategy
-
Buffers all values until the downstream consumes it.
- BufferSerializer - Class in io.smallrye.reactive.messaging.http.converters
- BufferSerializer() - Constructor for class io.smallrye.reactive.messaging.http.converters.BufferSerializer
- bufferSize() - Method in annotation type io.smallrye.reactive.messaging.annotations.OnOverflow
-
Deprecated.
- bufferSize() - Method in annotation type org.eclipse.microprofile.reactive.messaging.OnOverflow
- build() - Method in class io.smallrye.reactive.messaging.amqp.AmqpMessageBuilder
- build() - Method in class io.smallrye.reactive.messaging.amqp.OutgoingAmqpMetadata.OutgoingAmqpMetadataBuilder
- build() - Method in class io.smallrye.reactive.messaging.cloudevents.CloudEventMessageBuilder
- build() - Method in class io.smallrye.reactive.messaging.http.HttpMessage.HttpMessageBuilder
- build() - Method in class io.smallrye.reactive.messaging.http.HttpResponseMetadata.HttpResponseMetadataBuilder
- build() - Method in class io.smallrye.reactive.messaging.jms.JmsPropertiesBuilder
- build() - Method in class io.smallrye.reactive.messaging.jms.OutgoingJmsMessageMetadata.OutgoingJmsMessageMetadataBuilder
- build() - Method in class io.smallrye.reactive.messaging.kafka.OutgoingKafkaRecordMetadata.OutgoingKafkaRecordMetadataBuilder
- build(T, AttributesImpl, Collection<ExtensionFormat>) - Method in class io.smallrye.reactive.messaging.cloudevents.CloudEventMessageBuilder
- builder() - Static method in class io.smallrye.reactive.messaging.amqp.AmqpMessage
- builder() - Static method in class io.smallrye.reactive.messaging.amqp.OutgoingAmqpMetadata
- builder() - Static method in class io.smallrye.reactive.messaging.http.HttpMessage
- builder() - Static method in class io.smallrye.reactive.messaging.http.HttpResponseMetadata
- builder() - Static method in interface io.smallrye.reactive.messaging.jms.JmsProperties
-
Creates a builder object to create JMS Properties
- builder() - Static method in class io.smallrye.reactive.messaging.jms.OutgoingJmsMessageMetadata
- builder() - Static method in class io.smallrye.reactive.messaging.kafka.OutgoingKafkaRecordMetadata
- ByteArraySerializer - Class in io.smallrye.reactive.messaging.http.converters
- ByteArraySerializer() - Constructor for class io.smallrye.reactive.messaging.http.converters.ByteArraySerializer
- ByteBufferSerializer - Class in io.smallrye.reactive.messaging.http.converters
- ByteBufferSerializer() - Constructor for class io.smallrye.reactive.messaging.http.converters.ByteBufferSerializer
C
- CamelConnector - Class in io.smallrye.reactive.messaging.camel
- CamelConnector() - Constructor for class io.smallrye.reactive.messaging.camel.CamelConnector
- CamelConnectorCommonConfiguration - Class in io.smallrye.reactive.messaging.camel
-
Extracts the common configuration for the
smallrye-camel
connector. - CamelConnectorCommonConfiguration(Config) - Constructor for class io.smallrye.reactive.messaging.camel.CamelConnectorCommonConfiguration
-
Creates a new CamelConnectorCommonConfiguration.
- CamelConnectorIncomingConfiguration - Class in io.smallrye.reactive.messaging.camel
-
Extract the incoming configuration for the
smallrye-camel
connector. - CamelConnectorIncomingConfiguration(Config) - Constructor for class io.smallrye.reactive.messaging.camel.CamelConnectorIncomingConfiguration
-
Creates a new CamelConnectorIncomingConfiguration.
- CamelConnectorOutgoingConfiguration - Class in io.smallrye.reactive.messaging.camel
-
Extract the outgoing configuration for the
smallrye-camel
connector. - CamelConnectorOutgoingConfiguration(Config) - Constructor for class io.smallrye.reactive.messaging.camel.CamelConnectorOutgoingConfiguration
-
Creates a new CamelConnectorOutgoingConfiguration.
- CamelMessage<T> - Class in io.smallrye.reactive.messaging.camel
- CamelMessage(Exchange) - Constructor for class io.smallrye.reactive.messaging.camel.CamelMessage
- Channel - Annotation Type in io.smallrye.reactive.messaging.annotations
-
Deprecated.Use
Channel
instead. - Channel - Annotation Type in org.eclipse.microprofile.reactive.messaging
-
This qualifier indicates which channel should be injected / populated.
- CHANNEL_NAME_ATTRIBUTE - Static variable in interface org.eclipse.microprofile.reactive.messaging.spi.ConnectorFactory
-
The
channel-name
attribute name. - ChannelProducer - Class in io.smallrye.reactive.messaging.extension
- ChannelProducer() - Constructor for class io.smallrye.reactive.messaging.extension.ChannelProducer
- ChannelRegistar - Interface in io.smallrye.reactive.messaging
- ChannelRegistry - Interface in io.smallrye.reactive.messaging
- check(Class<?>, int) - Method in interface io.smallrye.reactive.messaging.MediatorConfigurationSupport.GenericTypeAssignable
- ClassUtils - Class in io.smallrye.reactive.messaging.helpers
-
Allows checking if a class can be assigned to a variable from another class.
- ClassWriter - Class in io.smallrye.reactive.messaging.connector
- cleanup() - Method in class io.smallrye.reactive.messaging.jms.JmsConnector
- clear() - Static method in class io.smallrye.reactive.messaging.connectors.InMemoryConnector
-
Switch back the channel to their original connector.
- clear() - Method in interface io.smallrye.reactive.messaging.connectors.InMemorySink
-
Clears the list of received messages.
- clear() - Static method in class io.smallrye.reactive.messaging.mqtt.Clients
-
Removed all the stored clients.
- ClientHolder(MqttClient, String, int, String) - Constructor for class io.smallrye.reactive.messaging.mqtt.Clients.ClientHolder
- Clients - Class in io.smallrye.reactive.messaging.mqtt
- Clients.ClientHolder - Class in io.smallrye.reactive.messaging.mqtt
- closeQuietly() - Method in class io.smallrye.reactive.messaging.kafka.impl.KafkaSink
- closeQuietly() - Method in class io.smallrye.reactive.messaging.kafka.impl.KafkaSource
- CloudEventMessage<T> - Interface in io.smallrye.reactive.messaging.cloudevents
-
Message extending Cloud Events.
- CloudEventMessageBuilder<T> - Class in io.smallrye.reactive.messaging.cloudevents
- CloudEventMessageBuilder() - Constructor for class io.smallrye.reactive.messaging.cloudevents.CloudEventMessageBuilder
- CloudEventSerializer - Class in io.smallrye.reactive.messaging.http.converters
- CloudEventSerializer() - Constructor for class io.smallrye.reactive.messaging.http.converters.CloudEventSerializer
- CommonConfigurationClassWriter - Class in io.smallrye.reactive.messaging.connector
-
Generates the parent class used by the incoming and outgoing configuration classes.
- CommonConfigurationClassWriter(ProcessingEnvironment) - Constructor for class io.smallrye.reactive.messaging.connector.CommonConfigurationClassWriter
- complete() - Method in interface io.smallrye.reactive.messaging.annotations.Emitter
-
Deprecated.Completes the stream.
- complete() - Method in interface io.smallrye.reactive.messaging.connectors.InMemorySource
-
Sends the completion event.
- complete() - Method in class io.smallrye.reactive.messaging.extension.EmitterImpl
- complete() - Method in class io.smallrye.reactive.messaging.extension.LegacyEmitterImpl
- complete() - Method in interface org.eclipse.microprofile.reactive.messaging.Emitter
-
Sends the completion event to the channel indicating that no other events will be sent afterward.
- COMPLETION_STAGE_OF_MESSAGE - io.smallrye.reactive.messaging.MediatorConfiguration.Production
- COMPLETION_STAGE_OF_PAYLOAD - io.smallrye.reactive.messaging.MediatorConfiguration.Production
- compute(Incomings, Outgoing, Blocking) - Method in class io.smallrye.reactive.messaging.DefaultMediatorConfiguration
- compute(List<Incoming>, Outgoing, Blocking) - Method in class io.smallrye.reactive.messaging.DefaultMediatorConfiguration
- CONCAT - io.smallrye.reactive.messaging.annotations.Merge.Mode
-
Concat the sources.
- config - Variable in class io.smallrye.reactive.messaging.amqp.AmqpConnectorCommonConfiguration
- config - Variable in class io.smallrye.reactive.messaging.aws.sns.SnsConnectorCommonConfiguration
- config - Variable in class io.smallrye.reactive.messaging.camel.CamelConnectorCommonConfiguration
- config - Variable in class io.smallrye.reactive.messaging.eventbus.VertxEventBusConnectorCommonConfiguration
- config - Variable in class io.smallrye.reactive.messaging.http.HttpConnectorCommonConfiguration
- config - Variable in class io.smallrye.reactive.messaging.impl.ConfiguredChannelFactory
- config - Variable in class io.smallrye.reactive.messaging.jms.JmsConnectorCommonConfiguration
- config - Variable in class io.smallrye.reactive.messaging.kafka.KafkaConnectorCommonConfiguration
- config - Variable in class io.smallrye.reactive.messaging.mqtt.MqttConnectorCommonConfiguration
- config - Variable in class io.smallrye.reactive.messaging.mqtt.server.MqttServerConnectorCommonConfiguration
- config() - Method in class io.smallrye.reactive.messaging.amqp.AmqpConnectorCommonConfiguration
- config() - Method in class io.smallrye.reactive.messaging.aws.sns.SnsConnectorCommonConfiguration
- config() - Method in class io.smallrye.reactive.messaging.camel.CamelConnectorCommonConfiguration
- config() - Method in class io.smallrye.reactive.messaging.eventbus.VertxEventBusConnectorCommonConfiguration
- config() - Method in class io.smallrye.reactive.messaging.http.HttpConnectorCommonConfiguration
- config() - Method in class io.smallrye.reactive.messaging.jms.JmsConnectorCommonConfiguration
- config() - Method in class io.smallrye.reactive.messaging.kafka.KafkaConnectorCommonConfiguration
- config() - Method in class io.smallrye.reactive.messaging.mqtt.MqttConnectorCommonConfiguration
- config() - Method in class io.smallrye.reactive.messaging.mqtt.server.MqttServerConnectorCommonConfiguration
- configuration - Variable in class io.smallrye.reactive.messaging.AbstractMediator
- configuration() - Method in class io.smallrye.reactive.messaging.AbstractMediator
- ConfigurationClassWriter - Class in io.smallrye.reactive.messaging.connector
- ConfigurationClassWriter(ProcessingEnvironment) - Constructor for class io.smallrye.reactive.messaging.connector.ConfigurationClassWriter
- ConfigurationDocWriter - Class in io.smallrye.reactive.messaging.connector
- ConfigurationDocWriter(ProcessingEnvironment) - Constructor for class io.smallrye.reactive.messaging.connector.ConfigurationDocWriter
- ConfiguredChannelFactory - Class in io.smallrye.reactive.messaging.impl
-
Look for stream factories and get instances.
- ConfiguredChannelFactory() - Constructor for class io.smallrye.reactive.messaging.impl.ConfiguredChannelFactory
- ConfiguredChannelFactory(Instance<IncomingConnectorFactory>, Instance<OutgoingConnectorFactory>, Instance<Config>, Instance<ChannelRegistry>, BeanManager) - Constructor for class io.smallrye.reactive.messaging.impl.ConfiguredChannelFactory
- connect() - Method in class io.smallrye.reactive.messaging.mqtt.Clients.ClientHolder
- Connector - Annotation Type in org.eclipse.microprofile.reactive.messaging.spi
-
Qualifier used on connector implementations to indicate the associated underlying transport.
- CONNECTOR - Static variable in class io.smallrye.reactive.messaging.connectors.InMemoryConnector
- CONNECTOR_ATTRIBUTE - Static variable in interface org.eclipse.microprofile.reactive.messaging.spi.ConnectorFactory
-
The
connector
attribute name. - CONNECTOR_NAME - Static variable in class io.smallrye.reactive.messaging.camel.CamelConnector
- CONNECTOR_NAME - Static variable in class io.smallrye.reactive.messaging.http.HttpConnector
- CONNECTOR_NAME - Static variable in class io.smallrye.reactive.messaging.jms.JmsConnector
-
The name of the connector:
smallrye-jms
- CONNECTOR_PREFIX - Static variable in interface org.eclipse.microprofile.reactive.messaging.spi.ConnectorFactory
-
Prefix used in the MicroProfile Config to configure properties shared by all the channels associated with a specific connector.
- ConnectorAttribute - Annotation Type in io.smallrye.reactive.messaging.annotations
-
Annotation used to declare an attribute on the connector.
- ConnectorAttribute.Direction - Enum in io.smallrye.reactive.messaging.annotations
- ConnectorAttributeProcessor - Class in io.smallrye.reactive.messaging.connector
- ConnectorAttributeProcessor() - Constructor for class io.smallrye.reactive.messaging.connector.ConnectorAttributeProcessor
- ConnectorAttributes - Annotation Type in io.smallrye.reactive.messaging.annotations
-
This class is used to allow multiple
ConnectorAttribute
declarations. - ConnectorConfig - Class in io.smallrye.reactive.messaging.impl
-
Implementation of config used to configured the different messaging provider / connector.
- ConnectorConfig(String, Config, String) - Constructor for class io.smallrye.reactive.messaging.impl.ConnectorConfig
- ConnectorFactory - Interface in org.eclipse.microprofile.reactive.messaging.spi
-
Parent class for
IncomingConnectorFactory
andOutgoingConnectorFactory
. - ConnectorLiteral - Class in org.eclipse.microprofile.reactive.messaging.spi
-
Supports inline instantiation of the
Connector
qualifier. - connectToUpstream(PublisherBuilder<? extends Message<?>>) - Method in class io.smallrye.reactive.messaging.AbstractMediator
- connectToUpstream(PublisherBuilder<? extends Message<?>>) - Method in class io.smallrye.reactive.messaging.ProcessorMediator
- connectToUpstream(PublisherBuilder<? extends Message<?>>) - Method in class io.smallrye.reactive.messaging.StreamTransformerMediator
- connectToUpstream(PublisherBuilder<? extends Message<?>>) - Method in class io.smallrye.reactive.messaging.SubscriberMediator
- consume(PubSubMessage) - Method in class gcp.pubsub.Receiver
- consume(KafkaRecord<String, String>) - Method in class acme.Receiver
- consume(Message<String>) - Method in class awssns.Receiver
- consumption() - Method in class io.smallrye.reactive.messaging.DefaultMediatorConfiguration
- consumption() - Method in interface io.smallrye.reactive.messaging.MediatorConfiguration
- convert(byte[]) - Method in class io.smallrye.reactive.messaging.http.converters.ByteArraySerializer
- convert(I) - Method in interface io.smallrye.reactive.messaging.http.converters.Converter
- convert(CloudEventMessage) - Method in class io.smallrye.reactive.messaging.http.converters.CloudEventSerializer
- convert(Buffer) - Method in class io.smallrye.reactive.messaging.http.converters.BufferSerializer
- convert(JsonArray) - Method in class io.smallrye.reactive.messaging.http.converters.JsonArraySerializer
- convert(JsonObject) - Method in class io.smallrye.reactive.messaging.http.converters.JsonObjectSerializer
- convert(String) - Method in class io.smallrye.reactive.messaging.http.converters.StringSerializer
- convert(ByteBuffer) - Method in class io.smallrye.reactive.messaging.http.converters.ByteBufferSerializer
- Converter<I,O> - Interface in io.smallrye.reactive.messaging.http.converters
- copy() - Method in class org.eclipse.microprofile.reactive.messaging.Metadata
-
Copies the current
Metadata
instance. - create() - Static method in class io.smallrye.reactive.messaging.http.HttpMessage.HttpMessageBuilder
- create(MediatorConfiguration) - Method in class io.smallrye.reactive.messaging.MediatorFactory
D
- decorate(PublisherBuilder<? extends Message<?>>) - Method in class io.smallrye.reactive.messaging.AbstractMediator
- decorate(PublisherBuilder<? extends Message<?>>, String) - Method in class io.smallrye.reactive.messaging.metrics.MetricDecorator
- decorate(PublisherBuilder<? extends Message<?>>, String) - Method in interface io.smallrye.reactive.messaging.PublisherDecorator
-
Decorate a publisher
- DEFAULT_WORKER_POOL - Static variable in annotation type io.smallrye.reactive.messaging.annotations.Blocking
- DefaultCloudEventMessage<T> - Class in io.smallrye.reactive.messaging.cloudevents
- DefaultCloudEventMessage(CloudEventImpl<T>) - Constructor for class io.smallrye.reactive.messaging.cloudevents.DefaultCloudEventMessage
- DefaultMediatorConfiguration - Class in io.smallrye.reactive.messaging
- DefaultMediatorConfiguration(Method, Bean<?>) - Constructor for class io.smallrye.reactive.messaging.DefaultMediatorConfiguration
- defaultValue() - Method in annotation type io.smallrye.reactive.messaging.annotations.ConnectorAttribute
- defineWorker(String, String, String) - Method in class io.smallrye.reactive.messaging.connectors.WorkerPoolRegistry
- deprecated() - Method in annotation type io.smallrye.reactive.messaging.annotations.ConnectorAttribute
- description() - Method in annotation type io.smallrye.reactive.messaging.annotations.ConnectorAttribute
- destroy() - Method in class io.smallrye.reactive.messaging.gcp.pubsub.PubSubManager
- destroy(Object) - Method in class io.smallrye.reactive.messaging.gcp.pubsub.PubSubConnector
- destroy(Object) - Method in class io.smallrye.reactive.messaging.mqtt.MqttConnector
- determineShape(List<?>, Object) - Method in class io.smallrye.reactive.messaging.MediatorConfigurationSupport
- direction() - Method in annotation type io.smallrye.reactive.messaging.annotations.ConnectorAttribute
- DROP - io.smallrye.reactive.messaging.annotations.OnOverflow.Strategy
-
Deprecated.Drops the most recent value if the downstream can't keep up.
- DROP - org.eclipse.microprofile.reactive.messaging.OnOverflow.Strategy
-
Drops the most recent value if the downstream can't keep up.
E
- Emitter<T> - Interface in io.smallrye.reactive.messaging.annotations
-
Deprecated.Use
Emitter
instead. - Emitter<T> - Interface in org.eclipse.microprofile.reactive.messaging
-
Interface used to feed a stream from an imperative piece of code.
- EmitterImpl<T> - Class in io.smallrye.reactive.messaging.extension
-
Implementation of the emitter pattern.
- EmitterImpl(String, String, long, long) - Constructor for class io.smallrye.reactive.messaging.extension.EmitterImpl
- empty() - Static method in class org.eclipse.microprofile.reactive.messaging.Metadata
-
Returns an empty set of metadata.
- equals(Object) - Method in class io.smallrye.reactive.messaging.gcp.pubsub.PubSubConfig
- equals(Object) - Method in class io.smallrye.reactive.messaging.gcp.pubsub.PubSubMessage
- equals(Type, Type) - Static method in class io.smallrye.reactive.messaging.helpers.TypeUtils
-
Check equality of types.
- error(Exception) - Method in interface io.smallrye.reactive.messaging.annotations.Emitter
-
Deprecated.Propagates an error in the stream.
- error(Exception) - Method in class io.smallrye.reactive.messaging.extension.EmitterImpl
- error(Exception) - Method in class io.smallrye.reactive.messaging.extension.LegacyEmitterImpl
- error(Exception) - Method in interface org.eclipse.microprofile.reactive.messaging.Emitter
-
Sends a failure event to the channel.
- EventBusMessage<T> - Class in io.smallrye.reactive.messaging.eventbus
- EventBusSink - Class in io.smallrye.reactive.messaging.eventbus
- executeWork(Handler<Promise<T>>, String, boolean) - Method in class io.smallrye.reactive.messaging.connectors.WorkerPoolRegistry
- ExecutionHolder - Class in io.smallrye.reactive.messaging.connectors
-
Provides common runtime services to connectors, such as a Vertx instance, to avoid duplicating the creation and cleanup of shared components across connectors.
- ExecutionHolder() - Constructor for class io.smallrye.reactive.messaging.connectors.ExecutionHolder
- ExecutionHolder(Vertx) - Constructor for class io.smallrye.reactive.messaging.connectors.ExecutionHolder
- ExecutionHolder(Instance<Vertx>) - Constructor for class io.smallrye.reactive.messaging.connectors.ExecutionHolder
- extend(JavaArchive) - Method in class io.smallrye.reactive.messaging.tck.SmallRyeReactiveMessagingExtender
F
- fail(Throwable) - Method in interface io.smallrye.reactive.messaging.connectors.InMemorySource
-
Sends a failure.
- FAIL - io.smallrye.reactive.messaging.annotations.OnOverflow.Strategy
-
Deprecated.Propagates a failure in case the downstream can't keep up.
- FAIL - org.eclipse.microprofile.reactive.messaging.OnOverflow.Strategy
-
Propagates a failure in case the downstream can't keep up.
- filter(PublisherBuilder<String>) - Method in class acme.Main
- from(HttpResponseMetadata) - Method in class io.smallrye.reactive.messaging.http.HttpResponseMetadata.HttpResponseMetadataBuilder
- from(Iterable<Object>) - Static method in class org.eclipse.microprofile.reactive.messaging.Metadata
- from(Message<T>) - Static method in class io.smallrye.reactive.messaging.cloudevents.CloudEventMessageBuilder
- from(Message<T>) - Static method in class io.smallrye.reactive.messaging.kafka.OutgoingKafkaRecord
G
- gcp.pubsub - package gcp.pubsub
- generate(ProcessingEnvironment, Connector, String, List<ConnectorAttribute>) - Static method in class io.smallrye.reactive.messaging.connector.CommonConfigurationClassWriter
- generateAllClasses(Connector, String, List<ConnectorAttribute>, List<ConnectorAttribute>, List<ConnectorAttribute>) - Method in class io.smallrye.reactive.messaging.connector.ConfigurationClassWriter
- generateIncomingDocumentation(Connector, List<ConnectorAttribute>, List<ConnectorAttribute>) - Method in class io.smallrye.reactive.messaging.connector.ConfigurationDocWriter
- generateOutgoingDocumentation(Connector, List<ConnectorAttribute>, List<ConnectorAttribute>) - Method in class io.smallrye.reactive.messaging.connector.ConfigurationDocWriter
- getAck() - Method in class io.smallrye.reactive.messaging.kafka.IncomingKafkaRecord
- getAck() - Method in class io.smallrye.reactive.messaging.kafka.OutgoingKafkaRecord
- getAck() - Method in interface org.eclipse.microprofile.reactive.messaging.Message
- getAcknowledgment() - Method in class io.smallrye.reactive.messaging.DefaultMediatorConfiguration
- getAcknowledgment() - Method in interface io.smallrye.reactive.messaging.MediatorConfiguration
- getAckOrCompletion(Message<?>) - Method in class io.smallrye.reactive.messaging.AbstractMediator
- getAcks() - Method in class io.smallrye.reactive.messaging.kafka.KafkaConnectorOutgoingConfiguration
-
Gets the acks value from the configuration.
- getAddress() - Method in class io.smallrye.reactive.messaging.amqp.AmqpConnectorCommonConfiguration
-
Gets the address value from the configuration.
- getAddress() - Method in class io.smallrye.reactive.messaging.amqp.AmqpMessage
- getAddress() - Method in class io.smallrye.reactive.messaging.amqp.IncomingAmqpMetadata
- getAddress() - Method in class io.smallrye.reactive.messaging.amqp.OutgoingAmqpMessage
- getAddress() - Method in class io.smallrye.reactive.messaging.amqp.OutgoingAmqpMetadata
- getAddress() - Method in class io.smallrye.reactive.messaging.eventbus.EventBusMessage
- getAddress() - Method in class io.smallrye.reactive.messaging.eventbus.VertxEventBusConnectorCommonConfiguration
-
Gets the address value from the configuration.
- getAmqpMessage() - Method in class io.smallrye.reactive.messaging.amqp.AmqpMessage
- getApplicationProperties() - Method in class io.smallrye.reactive.messaging.amqp.AmqpMessage
- getApplicationProperties() - Method in class io.smallrye.reactive.messaging.amqp.OutgoingAmqpMessage
- getAppUrl() - Method in class io.smallrye.reactive.messaging.aws.sns.SnsConnectorIncomingConfiguration
-
Gets the app-url value from the configuration.
- getAttributes() - Method in class io.smallrye.reactive.messaging.cloudevents.DefaultCloudEventMessage
- getAutoAcknowledgement() - Method in class io.smallrye.reactive.messaging.amqp.AmqpConnectorIncomingConfiguration
-
Gets the auto-acknowledgement value from the configuration.
- getAutoCleanSession() - Method in class io.smallrye.reactive.messaging.mqtt.MqttConnectorCommonConfiguration
-
Gets the auto-clean-session value from the configuration.
- getAutoGeneratedClientId() - Method in class io.smallrye.reactive.messaging.mqtt.MqttConnectorCommonConfiguration
-
Gets the auto-generated-client-id value from the configuration.
- getAutoGeneratedClientId() - Method in class io.smallrye.reactive.messaging.mqtt.server.MqttServerConnectorIncomingConfiguration
-
Gets the auto-generated-client-id value from the configuration.
- getAutoKeepAlive() - Method in class io.smallrye.reactive.messaging.mqtt.MqttConnectorCommonConfiguration
-
Gets the auto-keep-alive value from the configuration.
- getAutoOffsetReset() - Method in class io.smallrye.reactive.messaging.kafka.KafkaConnectorIncomingConfiguration
-
Gets the auto.offset.reset value from the configuration.
- getBean() - Method in class io.smallrye.reactive.messaging.DefaultMediatorConfiguration
- getBean() - Method in interface io.smallrye.reactive.messaging.MediatorConfiguration
- getBody() - Method in class io.smallrye.reactive.messaging.amqp.AmqpMessage
- getBody(Class<X>) - Method in class io.smallrye.reactive.messaging.jms.IncomingJmsMessageMetadata
- getBooleanProperty(String) - Method in class io.smallrye.reactive.messaging.jms.impl.ImmutableJmsProperties
- getBooleanProperty(String) - Method in class io.smallrye.reactive.messaging.jms.IncomingJmsMessageMetadata
- getBooleanProperty(String) - Method in interface io.smallrye.reactive.messaging.jms.JmsProperties
-
Returns the value of the
boolean
property with the specified name. - getBooleanProperty(String) - Method in class io.smallrye.reactive.messaging.jms.JmsPropertiesBuilder.OutgoingJmsProperties
- 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.amqp.AmqpConnectorIncomingConfiguration
-
Gets the broadcast value from the configuration.
- getBroadcast() - Method in class io.smallrye.reactive.messaging.aws.sns.SnsConnectorIncomingConfiguration
-
Gets the broadcast value from the configuration.
- getBroadcast() - Method in class io.smallrye.reactive.messaging.DefaultMediatorConfiguration
- getBroadcast() - Method in class io.smallrye.reactive.messaging.eventbus.VertxEventBusConnectorIncomingConfiguration
-
Gets the broadcast value from the configuration.
- getBroadcast() - Method in class io.smallrye.reactive.messaging.jms.JmsConnectorIncomingConfiguration
-
Gets the broadcast value from the configuration.
- getBroadcast() - Method in class io.smallrye.reactive.messaging.kafka.KafkaConnectorIncomingConfiguration
-
Gets the broadcast value from the configuration.
- getBroadcast() - Method in interface io.smallrye.reactive.messaging.MediatorConfiguration
- getBroadcast() - Method in class io.smallrye.reactive.messaging.mqtt.MqttConnectorIncomingConfiguration
-
Gets the broadcast value from the configuration.
- getBroadcast() - Method in class io.smallrye.reactive.messaging.mqtt.server.MqttServerConnectorIncomingConfiguration
-
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.
- getByteProperty(String) - Method in class io.smallrye.reactive.messaging.jms.impl.ImmutableJmsProperties
- getByteProperty(String) - Method in class io.smallrye.reactive.messaging.jms.IncomingJmsMessageMetadata
- getByteProperty(String) - Method in interface io.smallrye.reactive.messaging.jms.JmsProperties
-
Returns the value of the
byte
property with the specified name. - getByteProperty(String) - Method in class io.smallrye.reactive.messaging.jms.JmsPropertiesBuilder.OutgoingJmsProperties
- getCamelReactive() - Method in class io.smallrye.reactive.messaging.camel.CamelConnector
- getChannel() - Method in class io.smallrye.reactive.messaging.amqp.AmqpConnectorCommonConfiguration
- getChannel() - Method in class io.smallrye.reactive.messaging.aws.sns.SnsConnectorCommonConfiguration
- getChannel() - Method in class io.smallrye.reactive.messaging.camel.CamelConnectorCommonConfiguration
- getChannel() - Method in class io.smallrye.reactive.messaging.eventbus.VertxEventBusConnectorCommonConfiguration
- getChannel() - Method in class io.smallrye.reactive.messaging.http.HttpConnectorCommonConfiguration
- getChannel() - Method in class io.smallrye.reactive.messaging.jms.JmsConnectorCommonConfiguration
- getChannel() - Method in class io.smallrye.reactive.messaging.kafka.KafkaConnectorCommonConfiguration
- getChannel() - Method in class io.smallrye.reactive.messaging.mqtt.MqttConnectorCommonConfiguration
- getChannel() - Method in class io.smallrye.reactive.messaging.mqtt.server.MqttServerConnectorCommonConfiguration
- getClientId() - Method in class io.smallrye.reactive.messaging.jms.JmsConnectorCommonConfiguration
-
Gets the client-id value from the configuration.
- getClientId() - Method in class io.smallrye.reactive.messaging.mqtt.MqttConnectorCommonConfiguration
-
Gets the client-id value from the configuration.
- getClientId() - Method in class io.smallrye.reactive.messaging.mqtt.server.MqttMessage
- getClientOptionsName() - Method in class io.smallrye.reactive.messaging.amqp.AmqpConnectorCommonConfiguration
-
Gets the client-options-name value from the configuration.
- getCodec() - Method in class io.smallrye.reactive.messaging.eventbus.VertxEventBusConnectorOutgoingConfiguration
-
Gets the codec value from the configuration.
- getComputedSubscriber() - Method in class io.smallrye.reactive.messaging.AbstractMediator
- getComputedSubscriber() - Method in class io.smallrye.reactive.messaging.SubscriberMediator
- getConfigSources() - Method in class io.smallrye.reactive.messaging.impl.ConnectorConfig
- getConfiguration() - Method in class io.smallrye.reactive.messaging.AbstractMediator
- getConnectionFactoryName() - Method in class io.smallrye.reactive.messaging.jms.JmsConnectorCommonConfiguration
-
Gets the connection-factory-name value from the configuration.
- getConnectTimeout() - Method in class io.smallrye.reactive.messaging.amqp.AmqpConnectorCommonConfiguration
-
Gets the connect-timeout value from the configuration.
- getConnectTimeoutSeconds() - Method in class io.smallrye.reactive.messaging.mqtt.MqttConnectorCommonConfiguration
-
Gets the connect-timeout-seconds value from the configuration.
- getConsumption() - Method in class io.smallrye.reactive.messaging.MediatorConfigurationSupport.ValidationOutput
- getContainerId() - Method in class io.smallrye.reactive.messaging.amqp.AmqpConnectorCommonConfiguration
-
Gets the containerId value from the configuration.
- getContentEncoding() - Method in class io.smallrye.reactive.messaging.amqp.AmqpMessage
- getContentEncoding() - Method in class io.smallrye.reactive.messaging.amqp.IncomingAmqpMetadata
- getContentEncoding() - Method in class io.smallrye.reactive.messaging.amqp.OutgoingAmqpMessage
- getContentEncoding() - Method in class io.smallrye.reactive.messaging.amqp.OutgoingAmqpMetadata
- getContentType() - Method in class io.smallrye.reactive.messaging.amqp.AmqpMessage
- getContentType() - Method in class io.smallrye.reactive.messaging.amqp.IncomingAmqpMetadata
- getContentType() - Method in class io.smallrye.reactive.messaging.amqp.OutgoingAmqpMessage
- getContentType() - Method in class io.smallrye.reactive.messaging.amqp.OutgoingAmqpMetadata
- getConverter() - Method in class io.smallrye.reactive.messaging.http.HttpConnectorOutgoingConfiguration
-
Gets the converter value from the configuration.
- getCorrelationId() - Method in class io.smallrye.reactive.messaging.amqp.AmqpMessage
- getCorrelationId() - Method in class io.smallrye.reactive.messaging.amqp.IncomingAmqpMetadata
- getCorrelationId() - Method in class io.smallrye.reactive.messaging.amqp.OutgoingAmqpMessage
- getCorrelationId() - Method in class io.smallrye.reactive.messaging.amqp.OutgoingAmqpMetadata
- getCorrelationId() - Method in class io.smallrye.reactive.messaging.jms.IncomingJmsMessageMetadata
- getCorrelationId() - Method in class io.smallrye.reactive.messaging.jms.JmsConnectorOutgoingConfiguration
-
Gets the correlation-id value from the configuration.
- getCorrelationId() - Method in interface io.smallrye.reactive.messaging.jms.JmsMessageMetadata
- getCorrelationId() - Method in class io.smallrye.reactive.messaging.jms.OutgoingJmsMessageMetadata
- getCreationTime() - Method in class io.smallrye.reactive.messaging.amqp.AmqpMessage
- getCreationTime() - Method in class io.smallrye.reactive.messaging.amqp.IncomingAmqpMetadata
- getCredentialPath() - Method in class io.smallrye.reactive.messaging.gcp.pubsub.PubSubConfig
- getData() - Method in class io.smallrye.reactive.messaging.cloudevents.DefaultCloudEventMessage
- getDeliveryCount() - Method in class io.smallrye.reactive.messaging.amqp.AmqpMessage
- getDeliveryCount() - Method in class io.smallrye.reactive.messaging.amqp.IncomingAmqpMetadata
- getDeliveryDelay() - Method in class io.smallrye.reactive.messaging.jms.JmsConnectorOutgoingConfiguration
-
Gets the delivery-delay value from the configuration.
- getDeliveryMode() - Method in class io.smallrye.reactive.messaging.jms.IncomingJmsMessageMetadata
- getDeliveryMode() - Method in class io.smallrye.reactive.messaging.jms.JmsConnectorOutgoingConfiguration
-
Gets the delivery-mode value from the configuration.
- getDeliveryMode() - Method in interface io.smallrye.reactive.messaging.jms.JmsMessageMetadata
- getDeliveryMode() - Method in class io.smallrye.reactive.messaging.jms.OutgoingJmsMessageMetadata
- getDeliveryTime() - Method in class io.smallrye.reactive.messaging.jms.IncomingJmsMessageMetadata
- getDestination() - Method in class io.smallrye.reactive.messaging.jms.IncomingJmsMessageMetadata
- getDestination() - Method in class io.smallrye.reactive.messaging.jms.JmsConnectorCommonConfiguration
-
Gets the destination value from the configuration.
- getDestination() - Method in interface io.smallrye.reactive.messaging.jms.JmsMessageMetadata
- getDestination() - Method in class io.smallrye.reactive.messaging.jms.OutgoingJmsMessageMetadata
- getDestinationType() - Method in class io.smallrye.reactive.messaging.jms.JmsConnectorCommonConfiguration
-
Gets the destination-type value from the configuration.
- getDisableMessageId() - Method in class io.smallrye.reactive.messaging.jms.JmsConnectorOutgoingConfiguration
-
Gets the disable-message-id value from the configuration.
- getDisableMessageTimestamp() - Method in class io.smallrye.reactive.messaging.jms.JmsConnectorOutgoingConfiguration
-
Gets the disable-message-timestamp value from the configuration.
- getDoubleProperty(String) - Method in class io.smallrye.reactive.messaging.jms.impl.ImmutableJmsProperties
- getDoubleProperty(String) - Method in class io.smallrye.reactive.messaging.jms.IncomingJmsMessageMetadata
- getDoubleProperty(String) - Method in interface io.smallrye.reactive.messaging.jms.JmsProperties
-
Returns the value of the
double
property with the specified name. - getDoubleProperty(String) - Method in class io.smallrye.reactive.messaging.jms.JmsPropertiesBuilder.OutgoingJmsProperties
- getDurable() - Method in class io.smallrye.reactive.messaging.amqp.AmqpConnectorIncomingConfiguration
-
Gets the durable value from the configuration.
- getDurable() - Method in class io.smallrye.reactive.messaging.amqp.AmqpConnectorOutgoingConfiguration
-
Gets the durable value from the configuration.
- getDurable() - Method in class io.smallrye.reactive.messaging.jms.JmsConnectorIncomingConfiguration
-
Gets the durable value from the configuration.
- getEmitter(String) - Method in interface io.smallrye.reactive.messaging.ChannelRegistry
- getEmitter(String) - Method in class io.smallrye.reactive.messaging.impl.InternalChannelRegistry
- getEmitterNames() - Method in interface io.smallrye.reactive.messaging.ChannelRegistry
- getEmitterNames() - Method in class io.smallrye.reactive.messaging.impl.InternalChannelRegistry
- getEndpointUri() - Method in class io.smallrye.reactive.messaging.camel.CamelConnectorCommonConfiguration
-
Gets the endpoint-uri value from the configuration.
- getError() - Method in class io.smallrye.reactive.messaging.amqp.AmqpMessage
- getExchange() - Method in class io.smallrye.reactive.messaging.camel.CamelMessage
- getExchange() - Method in class io.smallrye.reactive.messaging.camel.IncomingExchangeMetadata
- getExchangePattern() - Method in class io.smallrye.reactive.messaging.camel.OutgoingExchangeMetadata
- getExpectReply() - Method in class io.smallrye.reactive.messaging.eventbus.VertxEventBusConnectorOutgoingConfiguration
-
Gets the expect-reply value from the configuration.
- getExpiration() - Method in class io.smallrye.reactive.messaging.jms.IncomingJmsMessageMetadata
- getExpiryTime() - Method in class io.smallrye.reactive.messaging.amqp.AmqpMessage
- getExpiryTime() - Method in class io.smallrye.reactive.messaging.amqp.IncomingAmqpMetadata
- getExtensions() - Method in class io.smallrye.reactive.messaging.cloudevents.DefaultCloudEventMessage
- getFailure() - Method in interface io.smallrye.reactive.messaging.connectors.InMemorySink
- getFetchMinBytes() - Method in class io.smallrye.reactive.messaging.kafka.KafkaConnectorIncomingConfiguration
-
Gets the fetch.min.bytes value from the configuration.
- getFloatProperty(String) - Method in class io.smallrye.reactive.messaging.jms.impl.ImmutableJmsProperties
- getFloatProperty(String) - Method in class io.smallrye.reactive.messaging.jms.IncomingJmsMessageMetadata
- getFloatProperty(String) - Method in interface io.smallrye.reactive.messaging.jms.JmsProperties
-
Returns the value of the
float
property with the specified name. - getFloatProperty(String) - Method in class io.smallrye.reactive.messaging.jms.JmsPropertiesBuilder.OutgoingJmsProperties
- getFromAlias(String, Class<T>) - Method in class io.smallrye.reactive.messaging.amqp.AmqpConnectorCommonConfiguration
-
Retrieves the value stored for the given alias.
- getFromAlias(String, Class<T>) - Method in class io.smallrye.reactive.messaging.aws.sns.SnsConnectorCommonConfiguration
-
Retrieves the value stored for the given alias.
- getFromAlias(String, Class<T>) - Method in class io.smallrye.reactive.messaging.camel.CamelConnectorCommonConfiguration
-
Retrieves the value stored for the given alias.
- getFromAlias(String, Class<T>) - Method in class io.smallrye.reactive.messaging.eventbus.VertxEventBusConnectorCommonConfiguration
-
Retrieves the value stored for the given alias.
- getFromAlias(String, Class<T>) - Method in class io.smallrye.reactive.messaging.http.HttpConnectorCommonConfiguration
-
Retrieves the value stored for the given alias.
- getFromAlias(String, Class<T>) - Method in class io.smallrye.reactive.messaging.jms.JmsConnectorCommonConfiguration
-
Retrieves the value stored for the given alias.
- getFromAlias(String, Class<T>) - Method in class io.smallrye.reactive.messaging.kafka.KafkaConnectorCommonConfiguration
-
Retrieves the value stored for the given alias.
- getFromAlias(String, Class<T>) - Method in class io.smallrye.reactive.messaging.mqtt.MqttConnectorCommonConfiguration
-
Retrieves the value stored for the given alias.
- getFromAlias(String, Class<T>) - Method in class io.smallrye.reactive.messaging.mqtt.server.MqttServerConnectorCommonConfiguration
-
Retrieves the value stored for the given alias.
- getFromAliasWithDefaultValue(String, Class<T>, T) - Method in class io.smallrye.reactive.messaging.amqp.AmqpConnectorCommonConfiguration
-
Retrieves the value stored for the given alias.
- getFromAliasWithDefaultValue(String, Class<T>, T) - Method in class io.smallrye.reactive.messaging.aws.sns.SnsConnectorCommonConfiguration
-
Retrieves the value stored for the given alias.
- getFromAliasWithDefaultValue(String, Class<T>, T) - Method in class io.smallrye.reactive.messaging.camel.CamelConnectorCommonConfiguration
-
Retrieves the value stored for the given alias.
- getFromAliasWithDefaultValue(String, Class<T>, T) - Method in class io.smallrye.reactive.messaging.eventbus.VertxEventBusConnectorCommonConfiguration
-
Retrieves the value stored for the given alias.
- getFromAliasWithDefaultValue(String, Class<T>, T) - Method in class io.smallrye.reactive.messaging.http.HttpConnectorCommonConfiguration
-
Retrieves the value stored for the given alias.
- getFromAliasWithDefaultValue(String, Class<T>, T) - Method in class io.smallrye.reactive.messaging.jms.JmsConnectorCommonConfiguration
-
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.
- getFromAliasWithDefaultValue(String, Class<T>, T) - Method in class io.smallrye.reactive.messaging.mqtt.MqttConnectorCommonConfiguration
-
Retrieves the value stored for the given alias.
- getFromAliasWithDefaultValue(String, Class<T>, T) - Method in class io.smallrye.reactive.messaging.mqtt.server.MqttServerConnectorCommonConfiguration
-
Retrieves the value stored for the given alias.
- getGetterBody(ConnectorAttribute, String) - Static method in class io.smallrye.reactive.messaging.connector.ClassWriter
- getGetterSignatureLine(ConnectorAttribute) - Static method in class io.smallrye.reactive.messaging.connector.ClassWriter
- getGroupId() - Method in class io.smallrye.reactive.messaging.amqp.AmqpMessage
- getGroupId() - Method in class io.smallrye.reactive.messaging.amqp.IncomingAmqpMetadata
- getGroupId() - Method in class io.smallrye.reactive.messaging.amqp.OutgoingAmqpMessage
- getGroupId() - Method in class io.smallrye.reactive.messaging.amqp.OutgoingAmqpMetadata
- getGroupId() - Method in class io.smallrye.reactive.messaging.kafka.KafkaConnectorIncomingConfiguration
-
Gets the group.id value from the configuration.
- getGroupSequence() - Method in class io.smallrye.reactive.messaging.amqp.AmqpMessage
- getGroupSequence() - Method in class io.smallrye.reactive.messaging.amqp.IncomingAmqpMetadata
- getHeader() - Method in class io.smallrye.reactive.messaging.amqp.AmqpMessage
- getHeader() - Method in class io.smallrye.reactive.messaging.amqp.IncomingAmqpMetadata
- getHeader(String) - Method in class io.smallrye.reactive.messaging.eventbus.EventBusMessage
- getHeaders() - Method in class io.smallrye.reactive.messaging.http.HttpMessage
- getHeaders() - Method in class io.smallrye.reactive.messaging.http.HttpRequestMetadata
- getHeaders() - Method in class io.smallrye.reactive.messaging.http.HttpResponseMetadata
- 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
- getHeaders(String) - Method in class io.smallrye.reactive.messaging.eventbus.EventBusMessage
- getHost() - Method in class io.smallrye.reactive.messaging.amqp.AmqpConnectorCommonConfiguration
-
Gets the host value from the configuration.
- getHost() - Method in class io.smallrye.reactive.messaging.aws.sns.SnsConnectorIncomingConfiguration
-
Gets the host value from the configuration.
- getHost() - Method in class io.smallrye.reactive.messaging.gcp.pubsub.PubSubConfig
- getHost() - Method in class io.smallrye.reactive.messaging.http.HttpConnectorIncomingConfiguration
-
Gets the host value from the configuration.
- getHost() - Method in class io.smallrye.reactive.messaging.mqtt.MqttConnectorCommonConfiguration
-
Gets the host value from the configuration.
- getHost() - Method in class io.smallrye.reactive.messaging.mqtt.server.MqttServerConnectorIncomingConfiguration
-
Gets the host value from the configuration.
- getId() - Method in class io.smallrye.reactive.messaging.amqp.IncomingAmqpMetadata
- getId() - Method in class io.smallrye.reactive.messaging.amqp.OutgoingAmqpMetadata
- getIncoming() - Method in class io.smallrye.reactive.messaging.DefaultMediatorConfiguration
- getIncoming() - Method in interface io.smallrye.reactive.messaging.MediatorConfiguration
- getIncomingNames() - Method in interface io.smallrye.reactive.messaging.ChannelRegistry
- getIncomingNames() - Method in class io.smallrye.reactive.messaging.impl.InternalChannelRegistry
- getIntProperty(String) - Method in class io.smallrye.reactive.messaging.jms.impl.ImmutableJmsProperties
- getIntProperty(String) - Method in class io.smallrye.reactive.messaging.jms.IncomingJmsMessageMetadata
- getIntProperty(String) - Method in interface io.smallrye.reactive.messaging.jms.JmsProperties
-
Returns the value of the
int
property with the specified name. - getIntProperty(String) - Method in class io.smallrye.reactive.messaging.jms.JmsPropertiesBuilder.OutgoingJmsProperties
- getInvokerClass() - Method in class io.smallrye.reactive.messaging.DefaultMediatorConfiguration
- getInvokerClass() - Method in interface io.smallrye.reactive.messaging.MediatorConfiguration
-
Implementation of the
Invoker
interface that can be used to invoke the method described by this configuration The invoker class can either have a no-arg constructor in which case it's expected to be look up the bean programmatically, or have a constructor that takes a single Object parameter - the bean to operate on - getKeepAliveSeconds() - Method in class io.smallrye.reactive.messaging.mqtt.MqttConnectorCommonConfiguration
-
Gets the keep-alive-seconds value from the configuration.
- 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
- 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.
- getLongProperty(String) - Method in class io.smallrye.reactive.messaging.jms.impl.ImmutableJmsProperties
- getLongProperty(String) - Method in class io.smallrye.reactive.messaging.jms.IncomingJmsMessageMetadata
- getLongProperty(String) - Method in interface io.smallrye.reactive.messaging.jms.JmsProperties
-
Returns the value of the
long
property with the specified name. - getLongProperty(String) - Method in class io.smallrye.reactive.messaging.jms.JmsPropertiesBuilder.OutgoingJmsProperties
- getMaxInflightMessages() - Method in class io.smallrye.reactive.messaging.kafka.KafkaConnectorOutgoingConfiguration
-
Gets the max-inflight-messages value from the configuration.
- getMaxInflightQueue() - Method in class io.smallrye.reactive.messaging.mqtt.MqttConnectorCommonConfiguration
-
Gets the max-inflight-queue value from the configuration.
- getMaxMessageSize() - Method in class io.smallrye.reactive.messaging.mqtt.MqttConnectorCommonConfiguration
-
Gets the max-message-size value from the configuration.
- getMaxMessageSize() - Method in class io.smallrye.reactive.messaging.mqtt.server.MqttServerConnectorIncomingConfiguration
-
Gets the max-message-size value from the configuration.
- getMerge() - Method in class io.smallrye.reactive.messaging.DefaultMediatorConfiguration
- getMerge() - Method in interface io.smallrye.reactive.messaging.MediatorConfiguration
- getMessage() - Method in class io.smallrye.reactive.messaging.gcp.pubsub.PubSubMessage
- getMessageId() - Method in class io.smallrye.reactive.messaging.amqp.AmqpMessage
- getMessageId() - Method in class io.smallrye.reactive.messaging.amqp.OutgoingAmqpMessage
- getMessageId() - Method in class io.smallrye.reactive.messaging.jms.IncomingJmsMessageMetadata
- getMessageId() - Method in interface io.smallrye.reactive.messaging.mqtt.MqttMessage
- getMessageId() - Method in class io.smallrye.reactive.messaging.mqtt.ReceivingMqttMessage
- getMessageId() - Method in class io.smallrye.reactive.messaging.mqtt.SendingMqttMessage
- getMessageId() - Method in class io.smallrye.reactive.messaging.mqtt.server.MqttMessage
- getMetadata() - Method in class io.smallrye.reactive.messaging.amqp.AmqpMessage
- getMetadata() - Method in class io.smallrye.reactive.messaging.amqp.OutgoingAmqpMessage
- getMetadata() - Method in class io.smallrye.reactive.messaging.camel.CamelMessage
- getMetadata() - Method in class io.smallrye.reactive.messaging.http.HttpMessage
- getMetadata() - Method in class io.smallrye.reactive.messaging.jms.IncomingJmsMessage
- getMetadata() - Method in class io.smallrye.reactive.messaging.kafka.IncomingKafkaRecord
- getMetadata() - Method in class io.smallrye.reactive.messaging.kafka.OutgoingKafkaRecord
- getMetadata() - Method in interface org.eclipse.microprofile.reactive.messaging.Message
- getMetadata(Class<? extends M>) - Method in interface org.eclipse.microprofile.reactive.messaging.Message
-
Retrieves the metadata associated with the given class.
- getMethod() - Method in class io.smallrye.reactive.messaging.DefaultMediatorConfiguration
- getMethod() - Method in class io.smallrye.reactive.messaging.http.HttpConnectorOutgoingConfiguration
-
Gets the method value from the configuration.
- getMethod() - Method in class io.smallrye.reactive.messaging.http.HttpMessage
- getMethod() - Method in class io.smallrye.reactive.messaging.http.HttpRequestMetadata
- getMethod() - Method in class io.smallrye.reactive.messaging.http.HttpResponseMetadata
- getMethod() - Method in interface io.smallrye.reactive.messaging.MediatorConfiguration
- getMethodAsString() - Method in class io.smallrye.reactive.messaging.AbstractMediator
- getMethodName(ConnectorAttribute) - Static method in class io.smallrye.reactive.messaging.connector.ClassWriter
- getMockSnsTopics() - Method in class io.smallrye.reactive.messaging.aws.sns.SnsConnectorCommonConfiguration
-
Gets the mock-sns-topics value from the configuration.
- getNoLocal() - Method in class io.smallrye.reactive.messaging.jms.JmsConnectorIncomingConfiguration
-
Gets the no-local value from the configuration.
- getNumberOfSubscriberBeforeConnecting() - Method in class io.smallrye.reactive.messaging.DefaultMediatorConfiguration
- getNumberOfSubscriberBeforeConnecting() - Method in interface io.smallrye.reactive.messaging.MediatorConfiguration
- getObjectProperty(String) - Method in class io.smallrye.reactive.messaging.jms.impl.ImmutableJmsProperties
- getObjectProperty(String) - Method in class io.smallrye.reactive.messaging.jms.IncomingJmsMessageMetadata
- getObjectProperty(String) - Method in interface io.smallrye.reactive.messaging.jms.JmsProperties
-
Returns the value of the Java object property with the specified name.
- getObjectProperty(String) - Method in class io.smallrye.reactive.messaging.jms.JmsPropertiesBuilder.OutgoingJmsProperties
- getOffset() - Method in class io.smallrye.reactive.messaging.kafka.IncomingKafkaRecord
- getOffset() - Method in class io.smallrye.reactive.messaging.kafka.IncomingKafkaRecordMetadata
- getOptionalValue(String, Class<T>) - Method in class io.smallrye.reactive.messaging.impl.ConnectorConfig
- getOutgoing() - Method in class io.smallrye.reactive.messaging.DefaultMediatorConfiguration
- getOutgoing() - Method in interface io.smallrye.reactive.messaging.MediatorConfiguration
- getOutgoingNames() - Method in interface io.smallrye.reactive.messaging.ChannelRegistry
- getOutgoingNames() - Method in class io.smallrye.reactive.messaging.impl.InternalChannelRegistry
- getParameterTypes() - Method in class io.smallrye.reactive.messaging.DefaultMediatorConfiguration
- getParameterTypes() - Method in interface io.smallrye.reactive.messaging.MediatorConfiguration
- 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
- getPassword() - Method in class io.smallrye.reactive.messaging.amqp.AmqpConnectorCommonConfiguration
-
Gets the password value from the configuration.
- getPassword() - Method in class io.smallrye.reactive.messaging.jms.JmsConnectorCommonConfiguration
-
Gets the password value from the configuration.
- getPassword() - Method in class io.smallrye.reactive.messaging.mqtt.MqttConnectorCommonConfiguration
-
Gets the password value from the configuration.
- getPath() - Method in class io.smallrye.reactive.messaging.http.HttpRequestMetadata
- getPayload() - Method in class io.smallrye.reactive.messaging.amqp.AmqpMessage
- getPayload() - Method in class io.smallrye.reactive.messaging.aws.sns.SnsMessage
- getPayload() - Method in class io.smallrye.reactive.messaging.camel.CamelMessage
- getPayload() - Method in class io.smallrye.reactive.messaging.cloudevents.DefaultCloudEventMessage
- getPayload() - Method in class io.smallrye.reactive.messaging.eventbus.EventBusMessage
- getPayload() - Method in class io.smallrye.reactive.messaging.gcp.pubsub.PubSubMessage
- getPayload() - Method in class io.smallrye.reactive.messaging.http.HttpMessage
- getPayload() - Method in class io.smallrye.reactive.messaging.jms.IncomingJmsMessage
- getPayload() - Method in class io.smallrye.reactive.messaging.kafka.IncomingKafkaRecord
- getPayload() - Method in class io.smallrye.reactive.messaging.kafka.OutgoingKafkaRecord
- getPayload() - Method in class io.smallrye.reactive.messaging.mqtt.ReceivingMqttMessage
- getPayload() - Method in class io.smallrye.reactive.messaging.mqtt.SendingMqttMessage
- getPayload() - Method in class io.smallrye.reactive.messaging.mqtt.server.MqttMessage
- getPayload() - Method in interface org.eclipse.microprofile.reactive.messaging.Message
- getPayload(Class<T>) - Method in class io.smallrye.reactive.messaging.camel.CamelMessage
- getPort() - Method in class io.smallrye.reactive.messaging.amqp.AmqpConnectorCommonConfiguration
-
Gets the port value from the configuration.
- getPort() - Method in class io.smallrye.reactive.messaging.aws.sns.SnsConnectorIncomingConfiguration
-
Gets the port value from the configuration.
- getPort() - Method in class io.smallrye.reactive.messaging.gcp.pubsub.PubSubConfig
- getPort() - Method in class io.smallrye.reactive.messaging.http.HttpConnectorIncomingConfiguration
-
Gets the port value from the configuration.
- getPort() - Method in class io.smallrye.reactive.messaging.mqtt.MqttConnectorCommonConfiguration
-
Gets the port value from the configuration.
- getPort() - Method in class io.smallrye.reactive.messaging.mqtt.server.MqttServerConnectorIncomingConfiguration
-
Gets the port value from the configuration.
- getPriority() - Method in class io.smallrye.reactive.messaging.amqp.AmqpMessage
- getPriority() - Method in class io.smallrye.reactive.messaging.amqp.IncomingAmqpMetadata
- getPriority() - Method in class io.smallrye.reactive.messaging.amqp.OutgoingAmqpMessage
- getPriority() - Method in class io.smallrye.reactive.messaging.amqp.OutgoingAmqpMetadata
- getPriority() - Method in class io.smallrye.reactive.messaging.jms.IncomingJmsMessageMetadata
- getPriority() - Method in class io.smallrye.reactive.messaging.jms.JmsConnectorOutgoingConfiguration
-
Gets the priority value from the configuration.
- getProduction() - Method in class io.smallrye.reactive.messaging.MediatorConfigurationSupport.ValidationOutput
- getProjectId() - Method in class io.smallrye.reactive.messaging.gcp.pubsub.PubSubConfig
- getProperties() - Method in class io.smallrye.reactive.messaging.amqp.IncomingAmqpMetadata
- getProperties() - Method in class io.smallrye.reactive.messaging.amqp.OutgoingAmqpMetadata
- getProperties() - Method in class io.smallrye.reactive.messaging.camel.OutgoingExchangeMetadata
- getProperties() - Method in class io.smallrye.reactive.messaging.jms.IncomingJmsMessageMetadata
- getProperties() - Method in interface io.smallrye.reactive.messaging.jms.JmsMessageMetadata
- getProperties() - Method in class io.smallrye.reactive.messaging.jms.JmsPropertiesBuilder.OutgoingJmsProperties
- getProperties() - Method in class io.smallrye.reactive.messaging.jms.OutgoingJmsMessageMetadata
- getPropertyNames() - Method in class io.smallrye.reactive.messaging.impl.ConnectorConfig
- getPropertyNames() - Method in class io.smallrye.reactive.messaging.jms.impl.ImmutableJmsProperties
- getPropertyNames() - Method in class io.smallrye.reactive.messaging.jms.IncomingJmsMessageMetadata
- getPropertyNames() - Method in interface io.smallrye.reactive.messaging.jms.JmsProperties
-
Returns an
Enumeration
of all the property names. - getPropertyNames() - Method in class io.smallrye.reactive.messaging.jms.JmsPropertiesBuilder.OutgoingJmsProperties
- getPublish() - Method in class io.smallrye.reactive.messaging.eventbus.VertxEventBusConnectorOutgoingConfiguration
-
Gets the publish value from the configuration.
- getPublisher() - Method in class io.smallrye.reactive.messaging.extension.EmitterImpl
- getPublisherBuilder(Config) - Method in class io.smallrye.reactive.messaging.amqp.AmqpConnector
- getPublisherBuilder(Config) - Method in class io.smallrye.reactive.messaging.aws.sns.SnsConnector
- getPublisherBuilder(Config) - Method in class io.smallrye.reactive.messaging.camel.CamelConnector
- getPublisherBuilder(Config) - Method in class io.smallrye.reactive.messaging.connectors.InMemoryConnector
- getPublisherBuilder(Config) - Method in class io.smallrye.reactive.messaging.eventbus.VertxEventBusConnector
- getPublisherBuilder(Config) - Method in class io.smallrye.reactive.messaging.gcp.pubsub.PubSubConnector
- getPublisherBuilder(Config) - Method in class io.smallrye.reactive.messaging.http.HttpConnector
- getPublisherBuilder(Config) - Method in class io.smallrye.reactive.messaging.jms.JmsConnector
- getPublisherBuilder(Config) - Method in class io.smallrye.reactive.messaging.kafka.KafkaConnector
- getPublisherBuilder(Config) - Method in class io.smallrye.reactive.messaging.mqtt.MqttConnector
- getPublisherBuilder(Config) - Method in class io.smallrye.reactive.messaging.mqtt.server.MqttServerConnector
- getPublisherBuilder(Config) - Method in interface org.eclipse.microprofile.reactive.messaging.spi.IncomingConnectorFactory
-
Creates a channel for the given configuration.
- getPublishers(String) - Method in interface io.smallrye.reactive.messaging.ChannelRegistry
- getPublishers(String) - Method in class io.smallrye.reactive.messaging.impl.InternalChannelRegistry
- getQos() - Method in class io.smallrye.reactive.messaging.mqtt.MqttConnectorCommonConfiguration
-
Gets the qos value from the configuration.
- getQosLevel() - Method in interface io.smallrye.reactive.messaging.mqtt.MqttMessage
- getQosLevel() - Method in class io.smallrye.reactive.messaging.mqtt.ReceivingMqttMessage
- getQosLevel() - Method in class io.smallrye.reactive.messaging.mqtt.SendingMqttMessage
- getQosLevel() - Method in class io.smallrye.reactive.messaging.mqtt.server.MqttMessage
- getQuery() - Method in class io.smallrye.reactive.messaging.http.HttpMessage
- getQuery() - Method in class io.smallrye.reactive.messaging.http.HttpRequestMetadata
- getQuery() - Method in class io.smallrye.reactive.messaging.http.HttpResponseMetadata
- getReceiveBufferSize() - Method in class io.smallrye.reactive.messaging.mqtt.server.MqttServerConnectorIncomingConfiguration
-
Gets the receive-buffer-size value from the configuration.
- getReconnectAttempts() - Method in class io.smallrye.reactive.messaging.amqp.AmqpConnectorCommonConfiguration
-
Gets the reconnect-attempts value from the configuration.
- getReconnectAttempts() - Method in class io.smallrye.reactive.messaging.mqtt.MqttConnectorCommonConfiguration
-
Gets the reconnect-attempts value from the configuration.
- getReconnectInterval() - Method in class io.smallrye.reactive.messaging.amqp.AmqpConnectorCommonConfiguration
-
Gets the reconnect-interval value from the configuration.
- getReconnectIntervalSeconds() - Method in class io.smallrye.reactive.messaging.mqtt.MqttConnectorCommonConfiguration
-
Gets the reconnect-interval-seconds value from the configuration.
- getRecord() - Method in class io.smallrye.reactive.messaging.kafka.IncomingKafkaRecordMetadata
- getReplyAddress() - Method in class io.smallrye.reactive.messaging.eventbus.EventBusMessage
- getReplyTo() - Method in class io.smallrye.reactive.messaging.jms.IncomingJmsMessageMetadata
- getReplyTo() - Method in class io.smallrye.reactive.messaging.jms.JmsConnectorOutgoingConfiguration
-
Gets the reply-to value from the configuration.
- getReplyTo() - Method in interface io.smallrye.reactive.messaging.jms.JmsMessageMetadata
- getReplyTo() - Method in class io.smallrye.reactive.messaging.jms.OutgoingJmsMessageMetadata
- getReplyToDestinationType() - Method in class io.smallrye.reactive.messaging.jms.JmsConnectorOutgoingConfiguration
-
Gets the reply-to-destination-type value from the configuration.
- 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.
- getReturnType() - Method in class io.smallrye.reactive.messaging.DefaultMediatorConfiguration
- getReturnType() - Method in interface io.smallrye.reactive.messaging.MediatorConfiguration
- getSelector() - Method in class io.smallrye.reactive.messaging.jms.JmsConnectorIncomingConfiguration
-
Gets the selector value from the configuration.
- getServerName() - Method in class io.smallrye.reactive.messaging.mqtt.MqttConnectorCommonConfiguration
-
Gets the server-name value from the configuration.
- getSessionMode() - Method in class io.smallrye.reactive.messaging.jms.JmsConnectorCommonConfiguration
-
Gets the session-mode value from the configuration.
- getShortProperty(String) - Method in class io.smallrye.reactive.messaging.jms.impl.ImmutableJmsProperties
- getShortProperty(String) - Method in class io.smallrye.reactive.messaging.jms.IncomingJmsMessageMetadata
- getShortProperty(String) - Method in interface io.smallrye.reactive.messaging.jms.JmsProperties
-
Returns the value of the
short
property with the specified name. - getShortProperty(String) - Method in class io.smallrye.reactive.messaging.jms.JmsPropertiesBuilder.OutgoingJmsProperties
- getSink() - Method in class io.smallrye.reactive.messaging.kafka.impl.KafkaSink
- getSink() - Method in class io.smallrye.reactive.messaging.mqtt.MqttSink
- getSnsUrl() - Method in class io.smallrye.reactive.messaging.aws.sns.SnsConnectorCommonConfiguration
-
Gets the sns-url value from the configuration.
- getSource() - Method in class io.smallrye.reactive.messaging.kafka.impl.KafkaSource
- getSsl() - Method in class io.smallrye.reactive.messaging.mqtt.MqttConnectorCommonConfiguration
-
Gets the ssl value from the configuration.
- getSsl() - Method in class io.smallrye.reactive.messaging.mqtt.server.MqttServerConnectorIncomingConfiguration
-
Gets the ssl value from the configuration.
- getStream() - Method in class io.smallrye.reactive.messaging.AbstractMediator
- getStream() - Method in class io.smallrye.reactive.messaging.ProcessorMediator
- getStream() - Method in class io.smallrye.reactive.messaging.PublisherMediator
- getStream() - Method in class io.smallrye.reactive.messaging.StreamTransformerMediator
- getStringProperty(String) - Method in class io.smallrye.reactive.messaging.jms.impl.ImmutableJmsProperties
- getStringProperty(String) - Method in class io.smallrye.reactive.messaging.jms.IncomingJmsMessageMetadata
- getStringProperty(String) - Method in interface io.smallrye.reactive.messaging.jms.JmsProperties
-
Returns the value of the
String
property with the specified name. - getStringProperty(String) - Method in class io.smallrye.reactive.messaging.jms.JmsPropertiesBuilder.OutgoingJmsProperties
- getSubject() - Method in class io.smallrye.reactive.messaging.amqp.AmqpMessage
- getSubject() - Method in class io.smallrye.reactive.messaging.amqp.IncomingAmqpMetadata
- getSubject() - Method in class io.smallrye.reactive.messaging.amqp.OutgoingAmqpMessage
- getSubject() - Method in class io.smallrye.reactive.messaging.amqp.OutgoingAmqpMetadata
- getSubject() - Method in class io.smallrye.reactive.messaging.aws.sns.SnsMessage
-
Get message subject of SNS notification.
- getSubscriberBuilder(Config) - Method in class io.smallrye.reactive.messaging.amqp.AmqpConnector
- getSubscriberBuilder(Config) - Method in class io.smallrye.reactive.messaging.aws.sns.SnsConnector
- getSubscriberBuilder(Config) - Method in class io.smallrye.reactive.messaging.camel.CamelConnector
- getSubscriberBuilder(Config) - Method in class io.smallrye.reactive.messaging.connectors.InMemoryConnector
- getSubscriberBuilder(Config) - Method in class io.smallrye.reactive.messaging.eventbus.VertxEventBusConnector
- getSubscriberBuilder(Config) - Method in class io.smallrye.reactive.messaging.gcp.pubsub.PubSubConnector
- getSubscriberBuilder(Config) - Method in class io.smallrye.reactive.messaging.http.HttpConnector
- getSubscriberBuilder(Config) - Method in class io.smallrye.reactive.messaging.jms.JmsConnector
- getSubscriberBuilder(Config) - Method in class io.smallrye.reactive.messaging.kafka.KafkaConnector
- getSubscriberBuilder(Config) - Method in class io.smallrye.reactive.messaging.mqtt.MqttConnector
- getSubscriberBuilder(Config) - Method in interface org.eclipse.microprofile.reactive.messaging.spi.OutgoingConnectorFactory
-
Creates a channel for the given configuration.
- getSubscribers(String) - Method in interface io.smallrye.reactive.messaging.ChannelRegistry
- getSubscribers(String) - Method in class io.smallrye.reactive.messaging.impl.InternalChannelRegistry
- getSubscription() - Method in class io.smallrye.reactive.messaging.gcp.pubsub.PubSubConfig
- getTimeout() - Method in class io.smallrye.reactive.messaging.eventbus.VertxEventBusConnectorOutgoingConfiguration
-
Gets the timeout value from the configuration.
- getTimeoutOnConnect() - Method in class io.smallrye.reactive.messaging.mqtt.server.MqttServerConnectorIncomingConfiguration
-
Gets the timeout-on-connect value from the configuration.
- getTimestamp() - Method in class io.smallrye.reactive.messaging.jms.IncomingJmsMessageMetadata
- 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 class io.smallrye.reactive.messaging.aws.sns.SnsConnectorCommonConfiguration
-
Gets the topic value from the configuration.
- getTopic() - Method in class io.smallrye.reactive.messaging.gcp.pubsub.PubSubConfig
- 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
- getTopic() - Method in class io.smallrye.reactive.messaging.mqtt.MqttConnectorCommonConfiguration
-
Gets the topic value from the configuration.
- getTopic() - Method in interface io.smallrye.reactive.messaging.mqtt.MqttMessage
- getTopic() - Method in class io.smallrye.reactive.messaging.mqtt.ReceivingMqttMessage
- getTopic() - Method in class io.smallrye.reactive.messaging.mqtt.SendingMqttMessage
- getTopic() - Method in class io.smallrye.reactive.messaging.mqtt.server.MqttMessage
- getTrustAll() - Method in class io.smallrye.reactive.messaging.mqtt.MqttConnectorCommonConfiguration
-
Gets the trust-all value from the configuration.
- getTtl() - Method in class io.smallrye.reactive.messaging.amqp.AmqpConnectorOutgoingConfiguration
-
Gets the ttl value from the configuration.
- getTtl() - Method in class io.smallrye.reactive.messaging.amqp.AmqpMessage
- getTtl() - Method in class io.smallrye.reactive.messaging.amqp.IncomingAmqpMetadata
- getTtl() - Method in class io.smallrye.reactive.messaging.amqp.OutgoingAmqpMessage
- getTtl() - Method in class io.smallrye.reactive.messaging.amqp.OutgoingAmqpMetadata
- getTtl() - Method in class io.smallrye.reactive.messaging.jms.JmsConnectorOutgoingConfiguration
-
Gets the ttl value from the configuration.
- getType() - Method in class io.smallrye.reactive.messaging.jms.IncomingJmsMessageMetadata
- getType() - Method in interface io.smallrye.reactive.messaging.jms.JmsMessageMetadata
- getType() - Method in class io.smallrye.reactive.messaging.jms.OutgoingJmsMessageMetadata
- getUrl() - Method in class io.smallrye.reactive.messaging.http.HttpConnectorOutgoingConfiguration
-
Gets the url value from the configuration.
- getUrl() - Method in class io.smallrye.reactive.messaging.http.HttpMessage
- getUrl() - Method in class io.smallrye.reactive.messaging.http.HttpResponseMetadata
- getUseAnonymousSender() - Method in class io.smallrye.reactive.messaging.amqp.AmqpConnectorOutgoingConfiguration
-
Gets the use-anonymous-sender value from the configuration.
- getUseBuilderTypes() - Method in class io.smallrye.reactive.messaging.MediatorConfigurationSupport.ValidationOutput
- getUseReplyAsAck() - Method in class io.smallrye.reactive.messaging.eventbus.VertxEventBusConnectorIncomingConfiguration
-
Gets the use-reply-as-ack value from the configuration.
- getUsername() - Method in class io.smallrye.reactive.messaging.amqp.AmqpConnectorCommonConfiguration
-
Gets the username value from the configuration.
- getUsername() - Method in class io.smallrye.reactive.messaging.jms.JmsConnectorCommonConfiguration
-
Gets the username value from the configuration.
- getUsername() - Method in class io.smallrye.reactive.messaging.mqtt.MqttConnectorCommonConfiguration
-
Gets the username value from the configuration.
- getUseSsl() - Method in class io.smallrye.reactive.messaging.amqp.AmqpConnectorCommonConfiguration
-
Gets the use-ssl value from the configuration.
- getValue(String, Class<T>) - Method in class io.smallrye.reactive.messaging.impl.ConnectorConfig
- 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.
- getWillFlag() - Method in class io.smallrye.reactive.messaging.mqtt.MqttConnectorCommonConfiguration
-
Gets the will-flag value from the configuration.
- getWillQos() - Method in class io.smallrye.reactive.messaging.mqtt.MqttConnectorCommonConfiguration
-
Gets the will-qos value from the configuration.
- getWillRetain() - Method in class io.smallrye.reactive.messaging.mqtt.MqttConnectorCommonConfiguration
-
Gets the will-retain value from the configuration.
- getWorkerPoolName() - Method in class io.smallrye.reactive.messaging.DefaultMediatorConfiguration
- getWorkerPoolName() - Method in interface io.smallrye.reactive.messaging.MediatorConfiguration
H
- hasAlias(ConnectorAttribute) - Static method in class io.smallrye.reactive.messaging.connector.ClassWriter
- hasCompleted() - Method in interface io.smallrye.reactive.messaging.connectors.InMemorySink
- hasDefaultValue(ConnectorAttribute) - Static method in class io.smallrye.reactive.messaging.connector.ClassWriter
- hasFailed() - Method in interface io.smallrye.reactive.messaging.connectors.InMemorySink
- hashCode() - Method in class io.smallrye.reactive.messaging.gcp.pubsub.PubSubConfig
- hashCode() - Method in class io.smallrye.reactive.messaging.gcp.pubsub.PubSubMessage
- hiddenFromDocumentation() - Method in annotation type io.smallrye.reactive.messaging.annotations.ConnectorAttribute
- HttpConnector - Class in io.smallrye.reactive.messaging.http
- HttpConnector() - Constructor for class io.smallrye.reactive.messaging.http.HttpConnector
- HttpConnectorCommonConfiguration - Class in io.smallrye.reactive.messaging.http
-
Extracts the common configuration for the
smallrye-http
connector. - HttpConnectorCommonConfiguration(Config) - Constructor for class io.smallrye.reactive.messaging.http.HttpConnectorCommonConfiguration
-
Creates a new HttpConnectorCommonConfiguration.
- HttpConnectorIncomingConfiguration - Class in io.smallrye.reactive.messaging.http
-
Extract the incoming configuration for the
smallrye-http
connector. - HttpConnectorIncomingConfiguration(Config) - Constructor for class io.smallrye.reactive.messaging.http.HttpConnectorIncomingConfiguration
-
Creates a new HttpConnectorIncomingConfiguration.
- HttpConnectorOutgoingConfiguration - Class in io.smallrye.reactive.messaging.http
-
Extract the outgoing configuration for the
smallrye-http
connector. - HttpConnectorOutgoingConfiguration(Config) - Constructor for class io.smallrye.reactive.messaging.http.HttpConnectorOutgoingConfiguration
-
Creates a new HttpConnectorOutgoingConfiguration.
- HttpMessage<T> - Class in io.smallrye.reactive.messaging.http
- HttpMessage.HttpMessageBuilder<T> - Class in io.smallrye.reactive.messaging.http
- HttpRequestMetadata - Class in io.smallrye.reactive.messaging.http
-
Metadata for incoming HTTP messages.
- HttpRequestMetadata(String, String, Map<String, List<String>>, Map<String, List<String>>) - Constructor for class io.smallrye.reactive.messaging.http.HttpRequestMetadata
- HttpResponseMetadata - Class in io.smallrye.reactive.messaging.http
-
Metadata for outgoing HTTP messages handled by the HTTP connector.
- HttpResponseMetadata(Map<String, List<String>>, String, String, Map<String, List<String>>) - Constructor for class io.smallrye.reactive.messaging.http.HttpResponseMetadata
- HttpResponseMetadata.HttpResponseMetadataBuilder - Class in io.smallrye.reactive.messaging.http
- HttpResponseMetadataBuilder() - Constructor for class io.smallrye.reactive.messaging.http.HttpResponseMetadata.HttpResponseMetadataBuilder
- HttpSource - Class in io.smallrye.reactive.messaging.http
I
- ImmutableJmsProperties - Class in io.smallrye.reactive.messaging.jms.impl
- ImmutableJmsProperties(Message) - Constructor for class io.smallrye.reactive.messaging.jms.impl.ImmutableJmsProperties
- Incoming - Annotation Type in org.eclipse.microprofile.reactive.messaging
-
Used to signify a subscriber to incoming messages.
- INCOMING - io.smallrye.reactive.messaging.annotations.ConnectorAttribute.Direction
- INCOMING_AND_OUTGOING - io.smallrye.reactive.messaging.annotations.ConnectorAttribute.Direction
- INCOMING_PREFIX - Static variable in interface org.eclipse.microprofile.reactive.messaging.spi.ConnectorFactory
-
Prefix used in the MicroProfile Config to configure an
incoming
channel. - IncomingAmqpMetadata - Class in io.smallrye.reactive.messaging.amqp
- IncomingAmqpMetadata(String, JsonObject, String, String, String, long, int, long, String, long, String, boolean, boolean, int, String, long, Header) - Constructor for class io.smallrye.reactive.messaging.amqp.IncomingAmqpMetadata
- IncomingConnectorFactory - Interface in org.eclipse.microprofile.reactive.messaging.spi
-
SPI used to implement a connector managing a source of messages for a specific transport.
- IncomingExchangeMetadata - Class in io.smallrye.reactive.messaging.camel
- IncomingExchangeMetadata(Exchange) - Constructor for class io.smallrye.reactive.messaging.camel.IncomingExchangeMetadata
- IncomingJmsMessage<T> - Class in io.smallrye.reactive.messaging.jms
- IncomingJmsMessageMetadata - Class in io.smallrye.reactive.messaging.jms
- IncomingJmsMessageMetadata(Message) - Constructor for class io.smallrye.reactive.messaging.jms.IncomingJmsMessageMetadata
- IncomingKafkaRecord<K,T> - Class in io.smallrye.reactive.messaging.kafka
- IncomingKafkaRecord(KafkaConsumer<K, T>, KafkaConsumerRecord<K, T>) - 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
- Incomings - Annotation Type in io.smallrye.reactive.messaging.annotations
-
This class is used to allow multiple
Incoming
declarations. - INDIVIDUAL_MESSAGE - io.smallrye.reactive.messaging.MediatorConfiguration.Production
- INDIVIDUAL_PAYLOAD - io.smallrye.reactive.messaging.MediatorConfiguration.Production
- init() - Method in class io.smallrye.reactive.messaging.camel.CamelConnector
- init() - Method in class io.smallrye.reactive.messaging.jms.JmsConnector
- initConnector() - Method in class io.smallrye.reactive.messaging.aws.sns.SnsConnector
- initialize() - Method in interface io.smallrye.reactive.messaging.ChannelRegistar
- initialize() - Method in class io.smallrye.reactive.messaging.gcp.pubsub.PubSubConnector
- initialize() - Method in class io.smallrye.reactive.messaging.impl.ConfiguredChannelFactory
- initialize() - Method in class io.smallrye.reactive.messaging.impl.LegacyConfiguredChannelFactory
- initialize(Object) - Method in class io.smallrye.reactive.messaging.AbstractMediator
- initialize(Object) - Method in class io.smallrye.reactive.messaging.ProcessorMediator
- initialize(Object) - Method in class io.smallrye.reactive.messaging.PublisherMediator
- initialize(Object) - Method in class io.smallrye.reactive.messaging.StreamTransformerMediator
- initialize(Object) - Method in class io.smallrye.reactive.messaging.SubscriberMediator
- initializeAndRun() - Method in class io.smallrye.reactive.messaging.extension.MediatorManager
- initializeEmitter(String, String, long, long) - Method in class io.smallrye.reactive.messaging.extension.MediatorManager
- initializeEmitters(Map<String, OnOverflow>) - Method in class io.smallrye.reactive.messaging.extension.MediatorManager
- InMemoryConnector - Class in io.smallrye.reactive.messaging.connectors
-
An implementation of connector used for testing applications without having to use external broker.
- InMemoryConnector() - Constructor for class io.smallrye.reactive.messaging.connectors.InMemoryConnector
- InMemorySink<T> - Interface in io.smallrye.reactive.messaging.connectors
-
Allows interacting with an in-memory sink.
- InMemorySource<T> - Interface in io.smallrye.reactive.messaging.connectors
-
Allows interacting with an in-memory source.
- input() - Method in class io.smallrye.reactive.messaging.http.converters.BufferSerializer
- input() - Method in class io.smallrye.reactive.messaging.http.converters.ByteArraySerializer
- input() - Method in class io.smallrye.reactive.messaging.http.converters.ByteBufferSerializer
- input() - Method in class io.smallrye.reactive.messaging.http.converters.CloudEventSerializer
- input() - Method in interface io.smallrye.reactive.messaging.http.converters.Converter
- input() - Method in class io.smallrye.reactive.messaging.http.converters.JsonArraySerializer
- input() - Method in class io.smallrye.reactive.messaging.http.converters.JsonObjectSerializer
- input() - Method in class io.smallrye.reactive.messaging.http.converters.StringSerializer
- InternalChannelRegistry - Class in io.smallrye.reactive.messaging.impl
- InternalChannelRegistry() - Constructor for class io.smallrye.reactive.messaging.impl.InternalChannelRegistry
- InvalidIndex - io.smallrye.reactive.messaging.MediatorConfigurationSupport.GenericTypeAssignable.Result
- invoke(Object...) - Method in class io.smallrye.reactive.messaging.AbstractMediator
- invoke(Object...) - Method in interface io.smallrye.reactive.messaging.Invoker
- invokeBlocking(Object...) - Method in class io.smallrye.reactive.messaging.AbstractMediator
- invokeBlocking(Object...) - Method in class io.smallrye.reactive.messaging.ProcessorMediator
- invokeBlocking(Object...) - Method in class io.smallrye.reactive.messaging.PublisherMediator
- Invoker - Interface in io.smallrye.reactive.messaging
- io.smallrye.reactive.messaging - package io.smallrye.reactive.messaging
- io.smallrye.reactive.messaging.amqp - package io.smallrye.reactive.messaging.amqp
- io.smallrye.reactive.messaging.annotations - package io.smallrye.reactive.messaging.annotations
- io.smallrye.reactive.messaging.aws.sns - package io.smallrye.reactive.messaging.aws.sns
- io.smallrye.reactive.messaging.camel - package io.smallrye.reactive.messaging.camel
- io.smallrye.reactive.messaging.cloudevents - package io.smallrye.reactive.messaging.cloudevents
- io.smallrye.reactive.messaging.connector - package io.smallrye.reactive.messaging.connector
- io.smallrye.reactive.messaging.connectors - package io.smallrye.reactive.messaging.connectors
- io.smallrye.reactive.messaging.eventbus - package io.smallrye.reactive.messaging.eventbus
- io.smallrye.reactive.messaging.example.eventclouds - package io.smallrye.reactive.messaging.example.eventclouds
- io.smallrye.reactive.messaging.extension - package io.smallrye.reactive.messaging.extension
- io.smallrye.reactive.messaging.gcp.pubsub - package io.smallrye.reactive.messaging.gcp.pubsub
- io.smallrye.reactive.messaging.helpers - package io.smallrye.reactive.messaging.helpers
- io.smallrye.reactive.messaging.http - package io.smallrye.reactive.messaging.http
- io.smallrye.reactive.messaging.http.converters - package io.smallrye.reactive.messaging.http.converters
- io.smallrye.reactive.messaging.impl - package io.smallrye.reactive.messaging.impl
- io.smallrye.reactive.messaging.jms - package io.smallrye.reactive.messaging.jms
- io.smallrye.reactive.messaging.jms.impl - package io.smallrye.reactive.messaging.jms.impl
- io.smallrye.reactive.messaging.kafka - package io.smallrye.reactive.messaging.kafka
- io.smallrye.reactive.messaging.kafka.impl - package io.smallrye.reactive.messaging.kafka.impl
- io.smallrye.reactive.messaging.metrics - package io.smallrye.reactive.messaging.metrics
- io.smallrye.reactive.messaging.mqtt - package io.smallrye.reactive.messaging.mqtt
- io.smallrye.reactive.messaging.mqtt.server - package io.smallrye.reactive.messaging.mqtt.server
- io.smallrye.reactive.messaging.tck - package io.smallrye.reactive.messaging.tck
- isAssignable(Class<?>, Class<?>) - Static method in class io.smallrye.reactive.messaging.helpers.ClassUtils
-
Checks if one
cls
can be assigned to a variable of anothertoClass
, like:Cls c = ...; ToClass x = c;
- isAssignable(Type, Type) - Static method in class io.smallrye.reactive.messaging.helpers.TypeUtils
-
Checks if the subject type may be implicitly cast to the target type following the Java generics rules.
- isBlank(String) - Static method in class io.smallrye.reactive.messaging.helpers.Validation
-
Checks if a given
string
is blank ornull
. - isBlocking() - Method in class io.smallrye.reactive.messaging.DefaultMediatorConfiguration
- isBlocking() - Method in interface io.smallrye.reactive.messaging.MediatorConfiguration
- isBlockingExecutionOrdered() - Method in class io.smallrye.reactive.messaging.DefaultMediatorConfiguration
- isBlockingExecutionOrdered() - Method in interface io.smallrye.reactive.messaging.MediatorConfiguration
- isBodyAssignableTo(Class<?>) - Method in class io.smallrye.reactive.messaging.jms.IncomingJmsMessageMetadata
- isCancelled() - Method in interface io.smallrye.reactive.messaging.annotations.Emitter
-
Deprecated.
- isCancelled() - Method in class io.smallrye.reactive.messaging.extension.EmitterImpl
- isCancelled() - Method in class io.smallrye.reactive.messaging.extension.LegacyEmitterImpl
- isCancelled() - Method in interface org.eclipse.microprofile.reactive.messaging.Emitter
- isConnected() - Method in class io.smallrye.reactive.messaging.AbstractMediator
- isConnected() - Method in class io.smallrye.reactive.messaging.ProcessorMediator
- isConnected() - Method in class io.smallrye.reactive.messaging.PublisherMediator
- isConnected() - Method in class io.smallrye.reactive.messaging.StreamTransformerMediator
- isConnected() - Method in class io.smallrye.reactive.messaging.SubscriberMediator
- isDuplicate() - Method in interface io.smallrye.reactive.messaging.mqtt.MqttMessage
- isDuplicate() - Method in class io.smallrye.reactive.messaging.mqtt.ReceivingMqttMessage
- isDuplicate() - Method in class io.smallrye.reactive.messaging.mqtt.SendingMqttMessage
- isDuplicate() - Method in class io.smallrye.reactive.messaging.mqtt.server.MqttMessage
- isDurable() - Method in class io.smallrye.reactive.messaging.amqp.AmqpMessage
- isDurable() - Method in class io.smallrye.reactive.messaging.amqp.IncomingAmqpMetadata
- isDurable() - Method in class io.smallrye.reactive.messaging.amqp.OutgoingAmqpMessage
- isDurable() - Method in class io.smallrye.reactive.messaging.amqp.OutgoingAmqpMetadata
- isFirstAcquirer() - Method in class io.smallrye.reactive.messaging.amqp.IncomingAmqpMetadata
- isInitialized() - Method in class io.smallrye.reactive.messaging.extension.MediatorManager
- isMockPubSubTopics() - Method in class io.smallrye.reactive.messaging.gcp.pubsub.PubSubConfig
- isReady() - Method in class io.smallrye.reactive.messaging.mqtt.MqttConnector
- isReady() - Method in class io.smallrye.reactive.messaging.mqtt.MqttSink
- isRedelivered() - Method in class io.smallrye.reactive.messaging.jms.IncomingJmsMessageMetadata
- isRequested() - Method in interface io.smallrye.reactive.messaging.annotations.Emitter
-
Deprecated.
- isRequested() - Method in class io.smallrye.reactive.messaging.extension.EmitterImpl
- isRequested() - Method in class io.smallrye.reactive.messaging.extension.LegacyEmitterImpl
- isRequested() - Method in interface org.eclipse.microprofile.reactive.messaging.Emitter
- isRetain() - Method in interface io.smallrye.reactive.messaging.mqtt.MqttMessage
- isRetain() - Method in class io.smallrye.reactive.messaging.mqtt.ReceivingMqttMessage
- isRetain() - Method in class io.smallrye.reactive.messaging.mqtt.SendingMqttMessage
- isRetain() - Method in class io.smallrye.reactive.messaging.mqtt.server.MqttMessage
- isTrue(boolean, String, Object...) - Static method in class io.smallrye.reactive.messaging.helpers.Validation
- iterator() - Method in class org.eclipse.microprofile.reactive.messaging.Metadata
J
- JmsConnector - Class in io.smallrye.reactive.messaging.jms
- JmsConnector() - Constructor for class io.smallrye.reactive.messaging.jms.JmsConnector
- JmsConnectorCommonConfiguration - Class in io.smallrye.reactive.messaging.jms
-
Extracts the common configuration for the
smallrye-jms
connector. - JmsConnectorCommonConfiguration(Config) - Constructor for class io.smallrye.reactive.messaging.jms.JmsConnectorCommonConfiguration
-
Creates a new JmsConnectorCommonConfiguration.
- JmsConnectorIncomingConfiguration - Class in io.smallrye.reactive.messaging.jms
-
Extract the incoming configuration for the
smallrye-jms
connector. - JmsConnectorIncomingConfiguration(Config) - Constructor for class io.smallrye.reactive.messaging.jms.JmsConnectorIncomingConfiguration
-
Creates a new JmsConnectorIncomingConfiguration.
- JmsConnectorOutgoingConfiguration - Class in io.smallrye.reactive.messaging.jms
-
Extract the outgoing configuration for the
smallrye-jms
connector. - JmsConnectorOutgoingConfiguration(Config) - Constructor for class io.smallrye.reactive.messaging.jms.JmsConnectorOutgoingConfiguration
-
Creates a new JmsConnectorOutgoingConfiguration.
- JmsMessageMetadata - Interface in io.smallrye.reactive.messaging.jms
- JmsProperties - Interface in io.smallrye.reactive.messaging.jms
-
Structure handling JMS Message properties.
- JmsPropertiesBuilder - Class in io.smallrye.reactive.messaging.jms
- JmsPropertiesBuilder() - Constructor for class io.smallrye.reactive.messaging.jms.JmsPropertiesBuilder
- JmsPropertiesBuilder.OutgoingJmsProperties - Class in io.smallrye.reactive.messaging.jms
- JmsPropertiesBuilder.Property<T> - Class in io.smallrye.reactive.messaging.jms
- JmsTask - Interface in io.smallrye.reactive.messaging.jms.impl
- JsonArraySerializer - Class in io.smallrye.reactive.messaging.http.converters
- JsonArraySerializer() - Constructor for class io.smallrye.reactive.messaging.http.converters.JsonArraySerializer
- JsonHelper - Class in io.smallrye.reactive.messaging.http
- JsonHelper - Class in io.smallrye.reactive.messaging.kafka.impl
- JsonHelper() - Constructor for class io.smallrye.reactive.messaging.http.JsonHelper
- JsonHelper() - Constructor for class io.smallrye.reactive.messaging.kafka.impl.JsonHelper
- JsonObjectSerializer - Class in io.smallrye.reactive.messaging.http.converters
- JsonObjectSerializer() - Constructor for class io.smallrye.reactive.messaging.http.converters.JsonObjectSerializer
K
- 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.
- KafkaMessage<K,T> - Interface in io.smallrye.reactive.messaging.kafka
-
Deprecated.Use
instead
- KafkaMessageMetadata<K> - Interface in io.smallrye.reactive.messaging.kafka
- KafkaRecord<K,T> - Interface in io.smallrye.reactive.messaging.kafka
- KafkaSink - Class in io.smallrye.reactive.messaging.kafka.impl
- KafkaSink(Vertx, KafkaConnectorOutgoingConfiguration) - Constructor for class io.smallrye.reactive.messaging.kafka.impl.KafkaSink
- KafkaSource<K,V> - Class in io.smallrye.reactive.messaging.kafka.impl
- KafkaSource(Vertx, KafkaConnectorIncomingConfiguration) - Constructor for class io.smallrye.reactive.messaging.kafka.impl.KafkaSource
L
- LATEST - io.smallrye.reactive.messaging.annotations.OnOverflow.Strategy
-
Deprecated.Keeps only the latest value, dropping any previous values if the downstream can't keep up.
- LATEST - org.eclipse.microprofile.reactive.messaging.OnOverflow.Strategy
-
Keeps only the latest value, dropping any previous value if the downstream can't keep up.
- LegacyConfiguredChannelFactory - Class in io.smallrye.reactive.messaging.impl
-
Look for stream factories and get instances.
- LegacyConfiguredChannelFactory() - Constructor for class io.smallrye.reactive.messaging.impl.LegacyConfiguredChannelFactory
- LegacyConfiguredChannelFactory(Instance<IncomingConnectorFactory>, Instance<OutgoingConnectorFactory>, Instance<Config>, Instance<ChannelRegistry>, BeanManager) - Constructor for class io.smallrye.reactive.messaging.impl.LegacyConfiguredChannelFactory
- LegacyEmitterImpl<T> - Class in io.smallrye.reactive.messaging.extension
-
Implementation of the old (legacy) Emitter interface.
- LOGGER - Static variable in class io.smallrye.reactive.messaging.connector.ClassWriter
- lookup(Object, String) - Static method in class io.smallrye.reactive.messaging.http.converters.Serializer
M
- main(String[]) - Static method in class acme.Main
- main(String[]) - Static method in class awssns.Main
- main(String[]) - Static method in class gcp.pubsub.Main
- main(String[]) - Static method in class io.smallrye.reactive.messaging.example.eventclouds.Main
- Main - Class in acme
- Main - Class in awssns
- Main - Class in gcp.pubsub
- Main - Class in io.smallrye.reactive.messaging.example.eventclouds
- Main() - Constructor for class acme.Main
- Main() - Constructor for class awssns.Main
- Main() - Constructor for class gcp.pubsub.Main
- Main() - Constructor for class io.smallrye.reactive.messaging.example.eventclouds.Main
- managePreProcessingAck() - Method in class io.smallrye.reactive.messaging.AbstractMediator
- mandatory() - Method in annotation type io.smallrye.reactive.messaging.annotations.ConnectorAttribute
- MANUAL - org.eclipse.microprofile.reactive.messaging.Acknowledgment.Strategy
-
Acknowledgment managed by the user code.
- MediatorConfiguration - Interface in io.smallrye.reactive.messaging
- MediatorConfiguration.Consumption - Enum in io.smallrye.reactive.messaging
- MediatorConfiguration.Production - Enum in io.smallrye.reactive.messaging
- MediatorConfigurationSupport - Class in io.smallrye.reactive.messaging
- MediatorConfigurationSupport(String, Class<?>, Class<?>[], MediatorConfigurationSupport.GenericTypeAssignable, MediatorConfigurationSupport.GenericTypeAssignable) - Constructor for class io.smallrye.reactive.messaging.MediatorConfigurationSupport
- MediatorConfigurationSupport.GenericTypeAssignable - Interface in io.smallrye.reactive.messaging
- MediatorConfigurationSupport.GenericTypeAssignable.Result - Enum in io.smallrye.reactive.messaging
- MediatorConfigurationSupport.ValidationOutput - Class in io.smallrye.reactive.messaging
- MediatorFactory - Class in io.smallrye.reactive.messaging
- MediatorFactory() - Constructor for class io.smallrye.reactive.messaging.MediatorFactory
- MediatorManager - Class in io.smallrye.reactive.messaging.extension
-
Class responsible for managing mediators
- MediatorManager() - Constructor for class io.smallrye.reactive.messaging.extension.MediatorManager
- Merge - Annotation Type in io.smallrye.reactive.messaging.annotations
-
Temporary annotation - must be copied to spec.
- MERGE - io.smallrye.reactive.messaging.annotations.Merge.Mode
-
Merge the different sources.
- Merge.Mode - Enum in io.smallrye.reactive.messaging.annotations
- message - Variable in class io.smallrye.reactive.messaging.amqp.AmqpMessage
- Message<T> - Interface in org.eclipse.microprofile.reactive.messaging
-
A message envelope.
- MESSAGE - io.smallrye.reactive.messaging.MediatorConfiguration.Consumption
- metadata - Variable in class io.smallrye.reactive.messaging.amqp.AmqpMessage
- Metadata - Class in org.eclipse.microprofile.reactive.messaging
-
Message metadata containers.
- methodAsString() - Method in class io.smallrye.reactive.messaging.DefaultMediatorConfiguration
- methodAsString() - Method in interface io.smallrye.reactive.messaging.MediatorConfiguration
- MetricDecorator - Class in io.smallrye.reactive.messaging.metrics
- MetricDecorator() - Constructor for class io.smallrye.reactive.messaging.metrics.MetricDecorator
- MqttConnector - Class in io.smallrye.reactive.messaging.mqtt
- MqttConnector() - Constructor for class io.smallrye.reactive.messaging.mqtt.MqttConnector
- MqttConnectorCommonConfiguration - Class in io.smallrye.reactive.messaging.mqtt
-
Extracts the common configuration for the
smallrye-mqtt
connector. - MqttConnectorCommonConfiguration(Config) - Constructor for class io.smallrye.reactive.messaging.mqtt.MqttConnectorCommonConfiguration
-
Creates a new MqttConnectorCommonConfiguration.
- MqttConnectorIncomingConfiguration - Class in io.smallrye.reactive.messaging.mqtt
-
Extract the incoming configuration for the
smallrye-mqtt
connector. - MqttConnectorIncomingConfiguration(Config) - Constructor for class io.smallrye.reactive.messaging.mqtt.MqttConnectorIncomingConfiguration
-
Creates a new MqttConnectorIncomingConfiguration.
- MqttConnectorOutgoingConfiguration - Class in io.smallrye.reactive.messaging.mqtt
-
Extract the outgoing configuration for the
smallrye-mqtt
connector. - MqttConnectorOutgoingConfiguration(Config) - Constructor for class io.smallrye.reactive.messaging.mqtt.MqttConnectorOutgoingConfiguration
-
Creates a new MqttConnectorOutgoingConfiguration.
- MqttHelpers - Class in io.smallrye.reactive.messaging.mqtt
- MqttMessage - Class in io.smallrye.reactive.messaging.mqtt.server
- MqttMessage<T> - Interface in io.smallrye.reactive.messaging.mqtt
- MqttServerConnector - Class in io.smallrye.reactive.messaging.mqtt.server
- MqttServerConnectorCommonConfiguration - Class in io.smallrye.reactive.messaging.mqtt.server
-
Extracts the common configuration for the
smallrye-mqtt-server
connector. - MqttServerConnectorCommonConfiguration(Config) - Constructor for class io.smallrye.reactive.messaging.mqtt.server.MqttServerConnectorCommonConfiguration
-
Creates a new MqttServerConnectorCommonConfiguration.
- MqttServerConnectorIncomingConfiguration - Class in io.smallrye.reactive.messaging.mqtt.server
-
Extract the incoming configuration for the
smallrye-mqtt-server
connector. - MqttServerConnectorIncomingConfiguration(Config) - Constructor for class io.smallrye.reactive.messaging.mqtt.server.MqttServerConnectorIncomingConfiguration
-
Creates a new MqttServerConnectorIncomingConfiguration.
- MqttServerConnectorOutgoingConfiguration - Class in io.smallrye.reactive.messaging.mqtt.server
-
Extract the outgoing configuration for the
smallrye-mqtt-server
connector. - MqttServerConnectorOutgoingConfiguration(Config) - Constructor for class io.smallrye.reactive.messaging.mqtt.server.MqttServerConnectorOutgoingConfiguration
-
Creates a new MqttServerConnectorOutgoingConfiguration.
- MqttServerQuickstart - Class in acme
- MqttServerQuickstart() - Constructor for class acme.MqttServerQuickstart
- MqttSink - Class in io.smallrye.reactive.messaging.mqtt
- MqttSink(Vertx, MqttConnectorOutgoingConfiguration) - Constructor for class io.smallrye.reactive.messaging.mqtt.MqttSink
- MqttSource - Class in io.smallrye.reactive.messaging.mqtt
- MqttSource(Vertx, MqttConnectorIncomingConfiguration) - Constructor for class io.smallrye.reactive.messaging.mqtt.MqttSource
- MyCloudEventProcessor - Class in io.smallrye.reactive.messaging.example.eventclouds
- MyCloudEventProcessor() - Constructor for class io.smallrye.reactive.messaging.example.eventclouds.MyCloudEventProcessor
- MyCloudEventSink - Class in io.smallrye.reactive.messaging.example.eventclouds
- MyCloudEventSink() - Constructor for class io.smallrye.reactive.messaging.example.eventclouds.MyCloudEventSink
- MyCloudEventSource - Class in io.smallrye.reactive.messaging.example.eventclouds
- MyCloudEventSource() - Constructor for class io.smallrye.reactive.messaging.example.eventclouds.MyCloudEventSource
N
- name() - Method in annotation type io.smallrye.reactive.messaging.annotations.ConnectorAttribute
- name() - Method in interface io.smallrye.reactive.messaging.connectors.InMemorySink
- name() - Method in interface io.smallrye.reactive.messaging.connectors.InMemorySource
- name() - Method in class io.smallrye.reactive.messaging.jms.JmsPropertiesBuilder.Property
- NO_VALUE - Static variable in annotation type io.smallrye.reactive.messaging.annotations.ConnectorAttribute
-
The constant used to indicate that the attribute has no default value or no alias.
- NONE - io.smallrye.reactive.messaging.annotations.OnOverflow.Strategy
-
Deprecated.The values are propagated without any back pressure strategy.
- NONE - io.smallrye.reactive.messaging.MediatorConfiguration.Consumption
- NONE - io.smallrye.reactive.messaging.MediatorConfiguration.Production
- NONE - org.eclipse.microprofile.reactive.messaging.Acknowledgment.Strategy
-
No acknowledgment is performed, neither implicitly or explicitly.
- NONE - org.eclipse.microprofile.reactive.messaging.OnOverflow.Strategy
-
The values are propagated without any back pressure strategy.
- noNullElements(T[], String) - Static method in class io.smallrye.reactive.messaging.helpers.Validation
- normalizeUpperBounds(Type[]) - Static method in class io.smallrye.reactive.messaging.helpers.TypeUtils
-
This method strips out the redundant upper bound types in type variable types and wildcard types (or it would with wildcard types if multiple upper bounds were allowed).
- NotAssignable - io.smallrye.reactive.messaging.MediatorConfigurationSupport.GenericTypeAssignable.Result
- notEmpty(T[], String) - Static method in class io.smallrye.reactive.messaging.helpers.Validation
- NotGeneric - io.smallrye.reactive.messaging.MediatorConfigurationSupport.GenericTypeAssignable.Result
- notNull(T, String) - Static method in class io.smallrye.reactive.messaging.helpers.Validation
O
- of(Object...) - Static method in class org.eclipse.microprofile.reactive.messaging.Metadata
-
Returns an instance of
Metadata
containing multiple values. - of(String) - Static method in class org.eclipse.microprofile.reactive.messaging.spi.ConnectorLiteral
-
Creates a new instance of
ConnectorLiteral
. - 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) - 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.KafkaMessage
-
Deprecated.Creates a new outgoing kafka message.
- of(String, K, T, Instant, int) - Static method in interface io.smallrye.reactive.messaging.kafka.KafkaRecord
-
Creates a new outgoing Kafka record.
- of(String, T) - Static method in interface io.smallrye.reactive.messaging.mqtt.MqttMessage
- of(String, T, MqttQoS) - Static method in interface io.smallrye.reactive.messaging.mqtt.MqttMessage
- of(String, T, MqttQoS, boolean) - Static method in interface io.smallrye.reactive.messaging.mqtt.MqttMessage
- of(String, T, Supplier<CompletionStage<Void>>) - Static method in interface io.smallrye.reactive.messaging.mqtt.MqttMessage
- of(K, T) - 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(T) - Static method in interface io.smallrye.reactive.messaging.mqtt.MqttMessage
- of(T) - Static method in interface org.eclipse.microprofile.reactive.messaging.Message
-
Create a message with the given payload.
- of(T, Iterable<Object>) - Static method in interface org.eclipse.microprofile.reactive.messaging.Message
-
Create a message with the given payload and metadata.
- of(T, Iterable<Object>, Supplier<CompletionStage<Void>>) - Static method in interface org.eclipse.microprofile.reactive.messaging.Message
-
Create a message with the given payload, metadata and ack function.
- of(T, Supplier<CompletionStage<Void>>) - Static method in interface org.eclipse.microprofile.reactive.messaging.Message
-
Create a message with the given payload and ack function.
- of(T, Metadata) - Static method in interface org.eclipse.microprofile.reactive.messaging.Message
-
Create a message with the given payload and metadata.
- of(T, Metadata, Supplier<CompletionStage<Void>>) - Static method in interface org.eclipse.microprofile.reactive.messaging.Message
-
Create a message with the given payload, metadata and ack function.
- onComplete() - Method in class io.smallrye.reactive.messaging.SubscriberWrapper
- ONE - io.smallrye.reactive.messaging.annotations.Merge.Mode
-
Pick the first source and use only this one.
- onError(Throwable) - Method in class io.smallrye.reactive.messaging.SubscriberWrapper
- onNext(T) - Method in class io.smallrye.reactive.messaging.SubscriberWrapper
- OnOverflow - Annotation Type in io.smallrye.reactive.messaging.annotations
-
Deprecated.Use
OnOverflow
instead - OnOverflow - Annotation Type in org.eclipse.microprofile.reactive.messaging
-
Allows configuring the back pressure policy on injected
Emitter
: - OnOverflow.Strategy - Enum in io.smallrye.reactive.messaging.annotations
-
Deprecated.The back pressure strategy.
- OnOverflow.Strategy - Enum in org.eclipse.microprofile.reactive.messaging
-
The back pressure strategy.
- onSubscribe(Subscription) - Method in class io.smallrye.reactive.messaging.SubscriberWrapper
- options() - Method in class acme.AmqpConfiguration
- options2() - Method in class acme.AmqpConfiguration
- ordered() - Method in annotation type io.smallrye.reactive.messaging.annotations.Blocking
-
Indicates whether the execution on the worker pool should be ordered.
- org.eclipse.microprofile.reactive.messaging - package org.eclipse.microprofile.reactive.messaging
-
IMPORTANT This package is a copy from the original package from the specification.
- org.eclipse.microprofile.reactive.messaging.spi - package org.eclipse.microprofile.reactive.messaging.spi
-
The MicroProfile Reactive Messaging API Connector SPI
- Outgoing - Annotation Type in org.eclipse.microprofile.reactive.messaging
-
Used to signify a publisher of outgoing messages.
- OUTGOING - io.smallrye.reactive.messaging.annotations.ConnectorAttribute.Direction
- OUTGOING_PREFIX - Static variable in interface org.eclipse.microprofile.reactive.messaging.spi.ConnectorFactory
-
Prefix used in the MicroProfile Config to configure an
outgoing
channel. - OutgoingAmqpMessage<T> - Class in io.smallrye.reactive.messaging.amqp
- OutgoingAmqpMessage(AmqpMessage, OutgoingAmqpMetadata) - Constructor for class io.smallrye.reactive.messaging.amqp.OutgoingAmqpMessage
- OutgoingAmqpMetadata - Class in io.smallrye.reactive.messaging.amqp
- OutgoingAmqpMetadata(String, JsonObject, String, String, String, String, String, boolean, int, String, long) - Constructor for class io.smallrye.reactive.messaging.amqp.OutgoingAmqpMetadata
- OutgoingAmqpMetadata.OutgoingAmqpMetadataBuilder - Class in io.smallrye.reactive.messaging.amqp
- OutgoingConnectorFactory - Interface in org.eclipse.microprofile.reactive.messaging.spi
-
SPI used to implement a connector managing a sink of messages for a specific transport.
- OutgoingExchangeMetadata - Class in io.smallrye.reactive.messaging.camel
- OutgoingExchangeMetadata() - Constructor for class io.smallrye.reactive.messaging.camel.OutgoingExchangeMetadata
- OutgoingJmsMessageMetadata - Class in io.smallrye.reactive.messaging.jms
- OutgoingJmsMessageMetadata(String, Destination, Destination, int, String, JmsProperties) - Constructor for class io.smallrye.reactive.messaging.jms.OutgoingJmsMessageMetadata
- OutgoingJmsMessageMetadata.OutgoingJmsMessageMetadataBuilder - Class in io.smallrye.reactive.messaging.jms
- OutgoingJmsMessageMetadataBuilder() - Constructor for class io.smallrye.reactive.messaging.jms.OutgoingJmsMessageMetadata.OutgoingJmsMessageMetadataBuilder
- OutgoingJmsProperties(Map<String, JmsPropertiesBuilder.Property<?>>) - Constructor for class io.smallrye.reactive.messaging.jms.JmsPropertiesBuilder.OutgoingJmsProperties
- OutgoingKafkaRecord<K,T> - Class in io.smallrye.reactive.messaging.kafka
- OutgoingKafkaRecord(String, K, T, Instant, int, Headers, Supplier<CompletionStage<Void>>) - 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
- output() - Method in interface io.smallrye.reactive.messaging.http.converters.Converter
- output() - Method in class io.smallrye.reactive.messaging.http.converters.Serializer
P
- PAYLOAD - io.smallrye.reactive.messaging.MediatorConfiguration.Consumption
- periodicallySendMessage() - Method in class awssns.BeanUsingAnEmitter
- periodicallySendMessage() - Method in class gcp.pubsub.BeanUsingAnEmitter
- periodicallySendMessageToKafka() - Method in class acme.BeanUsingAnEmitter
- POST_PROCESSING - org.eclipse.microprofile.reactive.messaging.Acknowledgment.Strategy
-
Acknowledgment performed automatically once the message has been processed.
- PRE_PROCESSING - org.eclipse.microprofile.reactive.messaging.Acknowledgment.Strategy
-
Acknowledgment performed automatically before the processing of the message by the user code.
- preDestroy() - Method in class io.smallrye.reactive.messaging.aws.sns.SnsConnector
-
Its being invoked before bean being destroyed.
- primitiveToWrapper(Class<?>) - Static method in class io.smallrye.reactive.messaging.helpers.ClassUtils
-
Converts the specified primitive Class object to its corresponding wrapper Class object.
- process(CloudEventMessage<String>) - Method in class io.smallrye.reactive.messaging.example.eventclouds.MyCloudEventProcessor
- process(Set<? extends TypeElement>, RoundEnvironment) - Method in class io.smallrye.reactive.messaging.connector.ConnectorAttributeProcessor
- processBroadcast(Object, Supplier<Integer>) - Method in class io.smallrye.reactive.messaging.MediatorConfigurationSupport
- processDefaultAcknowledgement(Shape, MediatorConfiguration.Consumption) - Method in class io.smallrye.reactive.messaging.MediatorConfigurationSupport
- ProcessingException - Exception in io.smallrye.reactive.messaging
- ProcessingException(String, Throwable) - Constructor for exception io.smallrye.reactive.messaging.ProcessingException
- processMerge(List<?>, Supplier<Merge.Mode>) - Method in class io.smallrye.reactive.messaging.MediatorConfigurationSupport
- PROCESSOR - io.smallrye.reactive.messaging.Shape
- ProcessorMediator - Class in io.smallrye.reactive.messaging
- ProcessorMediator(MediatorConfiguration) - Constructor for class io.smallrye.reactive.messaging.ProcessorMediator
- processSuppliedAcknowledgement(List<?>, Supplier<Acknowledgment.Strategy>) - Method in class io.smallrye.reactive.messaging.MediatorConfigurationSupport
- production() - Method in class io.smallrye.reactive.messaging.DefaultMediatorConfiguration
- production() - Method in interface io.smallrye.reactive.messaging.MediatorConfiguration
- propertyExists(String) - Method in class io.smallrye.reactive.messaging.jms.impl.ImmutableJmsProperties
- propertyExists(String) - Method in class io.smallrye.reactive.messaging.jms.IncomingJmsMessageMetadata
- propertyExists(String) - Method in interface io.smallrye.reactive.messaging.jms.JmsProperties
-
Indicates whether a property value exists.
- propertyExists(String) - Method in class io.smallrye.reactive.messaging.jms.JmsPropertiesBuilder.OutgoingJmsProperties
- publisher(PubSubConfig) - Method in class io.smallrye.reactive.messaging.gcp.pubsub.PubSubManager
- PUBLISHER - io.smallrye.reactive.messaging.Shape
- PublisherDecorator - Interface in io.smallrye.reactive.messaging
-
SPI to allow extension of publishers included in the final graph
- PublisherMediator - Class in io.smallrye.reactive.messaging
- PublisherMediator(MediatorConfiguration) - Constructor for class io.smallrye.reactive.messaging.PublisherMediator
- PubSubConfig - Class in io.smallrye.reactive.messaging.gcp.pubsub
- PubSubConfig(String, String, Path, boolean, String, Integer) - Constructor for class io.smallrye.reactive.messaging.gcp.pubsub.PubSubConfig
- PubSubConfig(String, String, Path, String, boolean, String, Integer) - Constructor for class io.smallrye.reactive.messaging.gcp.pubsub.PubSubConfig
- PubSubConnector - Class in io.smallrye.reactive.messaging.gcp.pubsub
- PubSubConnector() - Constructor for class io.smallrye.reactive.messaging.gcp.pubsub.PubSubConnector
- PubSubManager - Class in io.smallrye.reactive.messaging.gcp.pubsub
- PubSubManager() - Constructor for class io.smallrye.reactive.messaging.gcp.pubsub.PubSubManager
- PubSubMessage - Class in io.smallrye.reactive.messaging.gcp.pubsub
- PubSubMessage(PubsubMessage) - Constructor for class io.smallrye.reactive.messaging.gcp.pubsub.PubSubMessage
- PubSubMessage(PubsubMessage, AckReplyConsumer) - Constructor for class io.smallrye.reactive.messaging.gcp.pubsub.PubSubMessage
- PubSubMessageReceiver - Class in io.smallrye.reactive.messaging.gcp.pubsub
- PubSubMessageReceiver(MultiEmitter<? super Message<?>>) - Constructor for class io.smallrye.reactive.messaging.gcp.pubsub.PubSubMessageReceiver
- PubSubSource - Class in io.smallrye.reactive.messaging.gcp.pubsub
- PubSubSource(PubSubConfig, PubSubManager) - Constructor for class io.smallrye.reactive.messaging.gcp.pubsub.PubSubSource
- putProperty(String, Object) - Method in class io.smallrye.reactive.messaging.camel.OutgoingExchangeMetadata
R
- ReactiveMessagingExtension - Class in io.smallrye.reactive.messaging.extension
- ReactiveMessagingExtension() - Constructor for class io.smallrye.reactive.messaging.extension.ReactiveMessagingExtension
- receive(String) - Method in class io.smallrye.reactive.messaging.example.eventclouds.MyCloudEventSink
- received() - Method in interface io.smallrye.reactive.messaging.connectors.InMemorySink
- receiveMessage(PubsubMessage, AckReplyConsumer) - Method in class io.smallrye.reactive.messaging.gcp.pubsub.PubSubMessageReceiver
- Receiver - Class in acme
- Receiver - Class in awssns
- Receiver - Class in gcp.pubsub
- Receiver() - Constructor for class acme.Receiver
- Receiver() - Constructor for class awssns.Receiver
- Receiver() - Constructor for class gcp.pubsub.Receiver
- ReceivingMqttMessage - Class in io.smallrye.reactive.messaging.mqtt
- register(String, Emitter<?>) - Method in interface io.smallrye.reactive.messaging.ChannelRegistry
- register(String, Emitter<?>) - Method in class io.smallrye.reactive.messaging.impl.InternalChannelRegistry
- register(String, PublisherBuilder<? extends Message<?>>) - Method in interface io.smallrye.reactive.messaging.ChannelRegistry
- register(String, PublisherBuilder<? extends Message<?>>) - Method in class io.smallrye.reactive.messaging.impl.InternalChannelRegistry
- register(String, SubscriberBuilder<? extends Message<?>, Void>) - Method in interface io.smallrye.reactive.messaging.ChannelRegistry
- register(String, SubscriberBuilder<? extends Message<?>, Void>) - Method in class io.smallrye.reactive.messaging.impl.InternalChannelRegistry
- registry - Variable in class io.smallrye.reactive.messaging.impl.ConfiguredChannelFactory
- removeProperty(String) - Method in class io.smallrye.reactive.messaging.camel.OutgoingExchangeMetadata
- run() - Method in class io.smallrye.reactive.messaging.AbstractMediator
- run() - Method in class io.smallrye.reactive.messaging.SubscriberMediator
S
- send() - Method in class acme.Sender
- send(M) - Method in class io.smallrye.reactive.messaging.extension.EmitterImpl
- send(M) - Method in interface org.eclipse.microprofile.reactive.messaging.Emitter
-
Sends a payload to the channel.
- send(T) - Method in interface io.smallrye.reactive.messaging.annotations.Emitter
-
Deprecated.Sends a payload or a message to the stream.
- send(T) - Method in interface io.smallrye.reactive.messaging.connectors.InMemorySource
-
Sends a message or a payload to the channel.
- send(T) - Method in class io.smallrye.reactive.messaging.extension.EmitterImpl
- send(T) - Method in class io.smallrye.reactive.messaging.extension.LegacyEmitterImpl
- send(T) - Method in interface org.eclipse.microprofile.reactive.messaging.Emitter
-
Sends a payload to the channel.
- Sender - Class in acme
- Sender() - Constructor for class acme.Sender
- SendingMqttMessage<T> - Class in io.smallrye.reactive.messaging.mqtt
- Serializer<I> - Class in io.smallrye.reactive.messaging.http.converters
- Serializer() - Constructor for class io.smallrye.reactive.messaging.http.converters.Serializer
- setDecorators(Instance<PublisherDecorator>) - Method in class io.smallrye.reactive.messaging.AbstractMediator
- setExchangePattern(ExchangePattern) - Method in class io.smallrye.reactive.messaging.camel.OutgoingExchangeMetadata
- setInvoker(Invoker) - Method in class io.smallrye.reactive.messaging.AbstractMediator
- setWorkerPoolRegistry(WorkerPoolRegistry) - Method in class io.smallrye.reactive.messaging.AbstractMediator
- shape() - Method in class io.smallrye.reactive.messaging.DefaultMediatorConfiguration
- shape() - Method in interface io.smallrye.reactive.messaging.MediatorConfiguration
- Shape - Enum in io.smallrye.reactive.messaging
- sink(String) - Method in class acme.Main
- sink(String) - Method in class io.smallrye.reactive.messaging.connectors.InMemoryConnector
-
Retrieves an
InMemorySink
associated to the channel namedchannel
. - SmallRyeReactiveMessagingExtender - Class in io.smallrye.reactive.messaging.tck
- SmallRyeReactiveMessagingExtender() - Constructor for class io.smallrye.reactive.messaging.tck.SmallRyeReactiveMessagingExtender
- SnsConnector - Class in io.smallrye.reactive.messaging.aws.sns
-
Implement incoming/outgoing connection factories for Amazon Simple Notification Service reactive messaging.
- SnsConnector() - Constructor for class io.smallrye.reactive.messaging.aws.sns.SnsConnector
- SnsConnectorCommonConfiguration - Class in io.smallrye.reactive.messaging.aws.sns
-
Extracts the common configuration for the
smallrye-aws-sns
connector. - SnsConnectorCommonConfiguration(Config) - Constructor for class io.smallrye.reactive.messaging.aws.sns.SnsConnectorCommonConfiguration
-
Creates a new SnsConnectorCommonConfiguration.
- SnsConnectorIncomingConfiguration - Class in io.smallrye.reactive.messaging.aws.sns
-
Extract the incoming configuration for the
smallrye-aws-sns
connector. - SnsConnectorIncomingConfiguration(Config) - Constructor for class io.smallrye.reactive.messaging.aws.sns.SnsConnectorIncomingConfiguration
-
Creates a new SnsConnectorIncomingConfiguration.
- SnsConnectorOutgoingConfiguration - Class in io.smallrye.reactive.messaging.aws.sns
-
Extract the outgoing configuration for the
smallrye-aws-sns
connector. - SnsConnectorOutgoingConfiguration(Config) - Constructor for class io.smallrye.reactive.messaging.aws.sns.SnsConnectorOutgoingConfiguration
-
Creates a new SnsConnectorOutgoingConfiguration.
- SnsMessage - Class in io.smallrye.reactive.messaging.aws.sns
-
Implementation of
Message
for SNS. - SnsMessage(SnsNotification) - Constructor for class io.smallrye.reactive.messaging.aws.sns.SnsMessage
-
Constructor for AWS SNS.
- SnsMessage(String) - Constructor for class io.smallrye.reactive.messaging.aws.sns.SnsMessage
-
Constructor for fake SNS.
- SnsVerticle - Class in io.smallrye.reactive.messaging.aws.sns
-
Vert.x verticle that handles subscription to SNS topic and receive notifications from topic.
- SnsVerticle(String, String, int, boolean, String) - Constructor for class io.smallrye.reactive.messaging.aws.sns.SnsVerticle
-
Parameterized constructor.
- source() - Method in class acme.Main
- source() - Method in class io.smallrye.reactive.messaging.example.eventclouds.MyCloudEventSource
- source(MqttMessage) - Method in class acme.MqttServerQuickstart
- source(String) - Method in class io.smallrye.reactive.messaging.connectors.InMemoryConnector
-
Retrieves an
InMemorySource
associated to the channel namedchannel
. - start(Promise<Void>) - Method in class io.smallrye.reactive.messaging.aws.sns.SnsVerticle
- stop() - Method in class io.smallrye.reactive.messaging.http.HttpSource
- stream() - Method in class io.smallrye.reactive.messaging.mqtt.Clients.ClientHolder
- STREAM_OF_MESSAGE - io.smallrye.reactive.messaging.MediatorConfiguration.Consumption
- STREAM_OF_MESSAGE - io.smallrye.reactive.messaging.MediatorConfiguration.Production
- STREAM_OF_PAYLOAD - io.smallrye.reactive.messaging.MediatorConfiguration.Consumption
- STREAM_OF_PAYLOAD - io.smallrye.reactive.messaging.MediatorConfiguration.Production
- STREAM_TRANSFORMER - io.smallrye.reactive.messaging.Shape
- StreamTransformerMediator - Class in io.smallrye.reactive.messaging
- StreamTransformerMediator(MediatorConfiguration) - Constructor for class io.smallrye.reactive.messaging.StreamTransformerMediator
- STRICT_MODE_PROPERTY - Static variable in class io.smallrye.reactive.messaging.extension.MediatorManager
- StringSerializer - Class in io.smallrye.reactive.messaging.http.converters
- StringSerializer() - Constructor for class io.smallrye.reactive.messaging.http.converters.StringSerializer
- subscribe(Subscriber<? super T>) - Method in class io.smallrye.reactive.messaging.SubscriberWrapper
- subscriber(PubSubConfig, MultiEmitter<? super Message<?>>) - Method in class io.smallrye.reactive.messaging.gcp.pubsub.PubSubManager
- SUBSCRIBER - io.smallrye.reactive.messaging.Shape
- SubscriberMediator - Class in io.smallrye.reactive.messaging
- SubscriberMediator(MediatorConfiguration) - Constructor for class io.smallrye.reactive.messaging.SubscriberMediator
- SubscriberWrapper<I,T> - Class in io.smallrye.reactive.messaging
- SubscriberWrapper(Subscriber<I>, Function<T, I>, Function<T, CompletionStage<Void>>) - Constructor for class io.smallrye.reactive.messaging.SubscriberWrapper
- subscriptionAdminClient(PubSubConfig) - Method in class io.smallrye.reactive.messaging.gcp.pubsub.PubSubManager
- switchIncomingChannelsToInMemory(String...) - Static method in class io.smallrye.reactive.messaging.connectors.InMemoryConnector
-
Switch the given incoming channel to in-memory.
- switchOutgoingChannelsToInMemory(String...) - Static method in class io.smallrye.reactive.messaging.connectors.InMemoryConnector
-
Switch the given outgoing channel to in-memory.
T
- terminate(Object) - Method in class io.smallrye.reactive.messaging.amqp.AmqpConnector
- terminate(Object) - Method in class io.smallrye.reactive.messaging.connectors.ExecutionHolder
- terminate(Object) - Method in class io.smallrye.reactive.messaging.connectors.WorkerPoolRegistry
- terminate(Object) - Method in class io.smallrye.reactive.messaging.kafka.KafkaConnector
- terminate(Object) - Method in class io.smallrye.reactive.messaging.mqtt.server.MqttServerConnector
- topicAdminClient(PubSubConfig) - Method in class io.smallrye.reactive.messaging.gcp.pubsub.PubSubManager
- toString() - Method in class io.smallrye.reactive.messaging.cloudevents.DefaultCloudEventMessage
- toString() - Method in class io.smallrye.reactive.messaging.gcp.pubsub.PubSubConfig
- toString() - Method in class io.smallrye.reactive.messaging.gcp.pubsub.PubSubMessage
- toString(Type) - Static method in class io.smallrye.reactive.messaging.helpers.TypeUtils
- toUpperCase(String) - Method in class acme.Main
- type() - Method in annotation type io.smallrye.reactive.messaging.annotations.ConnectorAttribute
- TypeUtils - Class in io.smallrye.reactive.messaging.helpers
-
Utility methods focusing on type inspection, particularly with regard to generics.
U
- UNBOUNDED_BUFFER - io.smallrye.reactive.messaging.annotations.OnOverflow.Strategy
-
Deprecated.Buffers all values until the downstream consumes it.
- UNBOUNDED_BUFFER - org.eclipse.microprofile.reactive.messaging.OnOverflow.Strategy
-
Buffers all values until the downstream consumes it.
- UNI_OF_MESSAGE - io.smallrye.reactive.messaging.MediatorConfiguration.Production
- UNI_OF_PAYLOAD - io.smallrye.reactive.messaging.MediatorConfiguration.Production
- unwrap() - Method in class io.smallrye.reactive.messaging.amqp.AmqpMessage
- unwrap() - Method in class io.smallrye.reactive.messaging.eventbus.EventBusMessage
- unwrap(Class<C>) - Method in class io.smallrye.reactive.messaging.jms.IncomingJmsMessage
- unwrap(Class<C>) - Method in interface org.eclipse.microprofile.reactive.messaging.Message
-
Returns an object of the specified type to allow access to the connector-specific
Message
implementation, and other classes. - usesBuilderTypes() - Method in class io.smallrye.reactive.messaging.DefaultMediatorConfiguration
- usesBuilderTypes() - Method in interface io.smallrye.reactive.messaging.MediatorConfiguration
V
- validate() - Method in class io.smallrye.reactive.messaging.amqp.AmqpConnectorCommonConfiguration
- validate() - Method in class io.smallrye.reactive.messaging.amqp.AmqpConnectorIncomingConfiguration
- validate() - Method in class io.smallrye.reactive.messaging.amqp.AmqpConnectorOutgoingConfiguration
- validate() - Method in class io.smallrye.reactive.messaging.aws.sns.SnsConnectorCommonConfiguration
- validate() - Method in class io.smallrye.reactive.messaging.aws.sns.SnsConnectorIncomingConfiguration
- validate() - Method in class io.smallrye.reactive.messaging.aws.sns.SnsConnectorOutgoingConfiguration
- validate() - Method in class io.smallrye.reactive.messaging.camel.CamelConnectorCommonConfiguration
- validate() - Method in class io.smallrye.reactive.messaging.camel.CamelConnectorIncomingConfiguration
- validate() - Method in class io.smallrye.reactive.messaging.camel.CamelConnectorOutgoingConfiguration
- validate() - Method in class io.smallrye.reactive.messaging.eventbus.VertxEventBusConnectorCommonConfiguration
- validate() - Method in class io.smallrye.reactive.messaging.eventbus.VertxEventBusConnectorIncomingConfiguration
- validate() - Method in class io.smallrye.reactive.messaging.eventbus.VertxEventBusConnectorOutgoingConfiguration
- validate() - Method in class io.smallrye.reactive.messaging.http.HttpConnectorCommonConfiguration
- validate() - Method in class io.smallrye.reactive.messaging.http.HttpConnectorIncomingConfiguration
- validate() - Method in class io.smallrye.reactive.messaging.http.HttpConnectorOutgoingConfiguration
- validate() - Method in class io.smallrye.reactive.messaging.jms.JmsConnectorCommonConfiguration
- validate() - Method in class io.smallrye.reactive.messaging.jms.JmsConnectorIncomingConfiguration
- validate() - Method in class io.smallrye.reactive.messaging.jms.JmsConnectorOutgoingConfiguration
- 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
- validate() - Method in class io.smallrye.reactive.messaging.mqtt.MqttConnectorCommonConfiguration
- validate() - Method in class io.smallrye.reactive.messaging.mqtt.MqttConnectorIncomingConfiguration
- validate() - Method in class io.smallrye.reactive.messaging.mqtt.MqttConnectorOutgoingConfiguration
- validate() - Method in class io.smallrye.reactive.messaging.mqtt.server.MqttServerConnectorCommonConfiguration
- validate() - Method in class io.smallrye.reactive.messaging.mqtt.server.MqttServerConnectorIncomingConfiguration
- validate() - Method in class io.smallrye.reactive.messaging.mqtt.server.MqttServerConnectorOutgoingConfiguration
- validate(Shape, Acknowledgment.Strategy) - Method in class io.smallrye.reactive.messaging.MediatorConfigurationSupport
- validateBlocking(MediatorConfigurationSupport.ValidationOutput) - Method in class io.smallrye.reactive.messaging.MediatorConfigurationSupport
- Validation - Class in io.smallrye.reactive.messaging.helpers
- ValidationOutput(MediatorConfiguration.Production, MediatorConfiguration.Consumption) - Constructor for class io.smallrye.reactive.messaging.MediatorConfigurationSupport.ValidationOutput
- ValidationOutput(MediatorConfiguration.Production, MediatorConfiguration.Consumption, Boolean) - Constructor for class io.smallrye.reactive.messaging.MediatorConfigurationSupport.ValidationOutput
- value() - Method in annotation type io.smallrye.reactive.messaging.annotations.Blocking
-
Indicates the name of the worker pool to use for execution.
- value() - Method in annotation type io.smallrye.reactive.messaging.annotations.Broadcast
-
Indicates the number of subscribers required before dispatching the items.
- value() - Method in annotation type io.smallrye.reactive.messaging.annotations.Channel
-
Deprecated.The name of the channel.
- value() - Method in annotation type io.smallrye.reactive.messaging.annotations.ConnectorAttributes
- value() - Method in annotation type io.smallrye.reactive.messaging.annotations.Incomings
- value() - Method in annotation type io.smallrye.reactive.messaging.annotations.Merge
- value() - Method in annotation type io.smallrye.reactive.messaging.annotations.OnOverflow
-
Deprecated.
- value() - Method in class io.smallrye.reactive.messaging.jms.JmsPropertiesBuilder.Property
- value() - Method in annotation type org.eclipse.microprofile.reactive.messaging.Acknowledgment
- value() - Method in annotation type org.eclipse.microprofile.reactive.messaging.Channel
-
The name of the channel (indicated in the
@Outgoing
annotation. - value() - Method in annotation type org.eclipse.microprofile.reactive.messaging.Incoming
-
The name of the consumed channel.
- value() - Method in annotation type org.eclipse.microprofile.reactive.messaging.OnOverflow
- value() - Method in annotation type org.eclipse.microprofile.reactive.messaging.Outgoing
-
The name of the channel to publish to.
- value() - Method in annotation type org.eclipse.microprofile.reactive.messaging.spi.Connector
- value() - Method in class org.eclipse.microprofile.reactive.messaging.spi.ConnectorLiteral
- valueOf(String) - Static method in enum io.smallrye.reactive.messaging.annotations.ConnectorAttribute.Direction
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.smallrye.reactive.messaging.annotations.Merge.Mode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.smallrye.reactive.messaging.annotations.OnOverflow.Strategy
-
Deprecated.Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.smallrye.reactive.messaging.MediatorConfiguration.Consumption
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.smallrye.reactive.messaging.MediatorConfiguration.Production
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.smallrye.reactive.messaging.MediatorConfigurationSupport.GenericTypeAssignable.Result
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.smallrye.reactive.messaging.Shape
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.eclipse.microprofile.reactive.messaging.Acknowledgment.Strategy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.eclipse.microprofile.reactive.messaging.OnOverflow.Strategy
-
Returns the enum constant of this type with the specified name.
- values() - Static method in enum io.smallrye.reactive.messaging.annotations.ConnectorAttribute.Direction
-
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.annotations.Merge.Mode
-
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.annotations.OnOverflow.Strategy
-
Deprecated.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.MediatorConfiguration.Consumption
-
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.MediatorConfiguration.Production
-
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.MediatorConfigurationSupport.GenericTypeAssignable.Result
-
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.Shape
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.eclipse.microprofile.reactive.messaging.Acknowledgment.Strategy
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.eclipse.microprofile.reactive.messaging.OnOverflow.Strategy
-
Returns an array containing the constants of this enum type, in the order they are declared.
- vertx() - Method in class io.smallrye.reactive.messaging.connectors.ExecutionHolder
- VertxEventBusConnector - Class in io.smallrye.reactive.messaging.eventbus
- VertxEventBusConnector() - Constructor for class io.smallrye.reactive.messaging.eventbus.VertxEventBusConnector
- VertxEventBusConnectorCommonConfiguration - Class in io.smallrye.reactive.messaging.eventbus
-
Extracts the common configuration for the
smallrye-vertx-eventbus
connector. - VertxEventBusConnectorCommonConfiguration(Config) - Constructor for class io.smallrye.reactive.messaging.eventbus.VertxEventBusConnectorCommonConfiguration
-
Creates a new VertxEventBusConnectorCommonConfiguration.
- VertxEventBusConnectorIncomingConfiguration - Class in io.smallrye.reactive.messaging.eventbus
-
Extract the incoming configuration for the
smallrye-vertx-eventbus
connector. - VertxEventBusConnectorIncomingConfiguration(Config) - Constructor for class io.smallrye.reactive.messaging.eventbus.VertxEventBusConnectorIncomingConfiguration
-
Creates a new VertxEventBusConnectorIncomingConfiguration.
- VertxEventBusConnectorOutgoingConfiguration - Class in io.smallrye.reactive.messaging.eventbus
-
Extract the outgoing configuration for the
smallrye-vertx-eventbus
connector. - VertxEventBusConnectorOutgoingConfiguration(Config) - Constructor for class io.smallrye.reactive.messaging.eventbus.VertxEventBusConnectorOutgoingConfiguration
-
Creates a new VertxEventBusConnectorOutgoingConfiguration.
W
- WeavingException - Exception in io.smallrye.reactive.messaging
- WeavingException(String) - Constructor for exception io.smallrye.reactive.messaging.WeavingException
- WeavingException(String, String, int) - Constructor for exception io.smallrye.reactive.messaging.WeavingException
- WeavingException(String, Throwable) - Constructor for exception io.smallrye.reactive.messaging.WeavingException
-
Used when a synchronous error is caught during the subscription
- WeavingException(List<String>, Throwable) - Constructor for exception io.smallrye.reactive.messaging.WeavingException
- with(Object) - Method in class org.eclipse.microprofile.reactive.messaging.Metadata
-
Creates a new instance of
Metadata
with the current entries, plusmeta
. - with(String, boolean) - Method in class io.smallrye.reactive.messaging.jms.JmsPropertiesBuilder
- with(String, byte) - Method in class io.smallrye.reactive.messaging.jms.JmsPropertiesBuilder
- with(String, double) - Method in class io.smallrye.reactive.messaging.jms.JmsPropertiesBuilder
- with(String, float) - Method in class io.smallrye.reactive.messaging.jms.JmsPropertiesBuilder
- with(String, int) - Method in class io.smallrye.reactive.messaging.jms.JmsPropertiesBuilder
- with(String, long) - Method in class io.smallrye.reactive.messaging.jms.JmsPropertiesBuilder
- with(String, short) - Method in class io.smallrye.reactive.messaging.jms.JmsPropertiesBuilder
- with(String, String) - Method in class io.smallrye.reactive.messaging.jms.JmsPropertiesBuilder
- withAck(Supplier<CompletionStage<Void>>) - Method in class io.smallrye.reactive.messaging.http.HttpMessage.HttpMessageBuilder
- withAck(Supplier<CompletionStage<Void>>) - Method in class io.smallrye.reactive.messaging.kafka.OutgoingKafkaRecord
- withAck(Supplier<CompletionStage<Void>>) - Method in interface io.smallrye.reactive.messaging.mqtt.MqttMessage
- withAck(Supplier<CompletionStage<Void>>) - Method in interface org.eclipse.microprofile.reactive.messaging.Message
-
Creates a new instance of
Message
with the given acknowledgement supplier. - withAddress(String) - Method in class io.smallrye.reactive.messaging.amqp.AmqpMessageBuilder
- withAddress(String) - Method in class io.smallrye.reactive.messaging.amqp.OutgoingAmqpMetadata.OutgoingAmqpMetadataBuilder
- withApplicationProperties(JsonObject) - Method in class io.smallrye.reactive.messaging.amqp.AmqpMessageBuilder
- withBody(String) - Method in class io.smallrye.reactive.messaging.amqp.AmqpMessageBuilder
- withBooleanAsBody(boolean) - Method in class io.smallrye.reactive.messaging.amqp.AmqpMessageBuilder
- withBufferAsBody(Buffer) - Method in class io.smallrye.reactive.messaging.amqp.AmqpMessageBuilder
- withByteAsBody(byte) - Method in class io.smallrye.reactive.messaging.amqp.AmqpMessageBuilder
- withCharAsBody(char) - Method in class io.smallrye.reactive.messaging.amqp.AmqpMessageBuilder
- withContentEncoding(String) - Method in class io.smallrye.reactive.messaging.amqp.AmqpMessageBuilder
- withContentEncoding(String) - Method in class io.smallrye.reactive.messaging.amqp.OutgoingAmqpMetadata.OutgoingAmqpMetadataBuilder
- withContentType(String) - Method in class io.smallrye.reactive.messaging.amqp.AmqpMessageBuilder
- withContentType(String) - Method in class io.smallrye.reactive.messaging.amqp.OutgoingAmqpMetadata.OutgoingAmqpMetadataBuilder
- withCorrelationId(String) - Method in class io.smallrye.reactive.messaging.amqp.AmqpMessageBuilder
- withCorrelationId(String) - Method in class io.smallrye.reactive.messaging.amqp.OutgoingAmqpMetadata.OutgoingAmqpMetadataBuilder
- withCorrelationId(String) - Method in class io.smallrye.reactive.messaging.jms.OutgoingJmsMessageMetadata.OutgoingJmsMessageMetadataBuilder
- withData(T) - Method in class io.smallrye.reactive.messaging.cloudevents.CloudEventMessageBuilder
- withDataContentType(String) - Method in class io.smallrye.reactive.messaging.cloudevents.CloudEventMessageBuilder
- withDataschema(URI) - Method in class io.smallrye.reactive.messaging.cloudevents.CloudEventMessageBuilder
- withDeliveryMode(int) - Method in class io.smallrye.reactive.messaging.jms.OutgoingJmsMessageMetadata.OutgoingJmsMessageMetadataBuilder
- withDestination(Destination) - Method in class io.smallrye.reactive.messaging.jms.OutgoingJmsMessageMetadata.OutgoingJmsMessageMetadataBuilder
- withDoubleAsBody(double) - Method in class io.smallrye.reactive.messaging.amqp.AmqpMessageBuilder
- withDurable(boolean) - Method in class io.smallrye.reactive.messaging.amqp.AmqpMessageBuilder
- withDurable(boolean) - Method in class io.smallrye.reactive.messaging.amqp.OutgoingAmqpMetadata.OutgoingAmqpMetadataBuilder
- withExtension(ExtensionFormat) - Method in class io.smallrye.reactive.messaging.cloudevents.CloudEventMessageBuilder
- withFloatAsBody(float) - Method in class io.smallrye.reactive.messaging.amqp.AmqpMessageBuilder
- withGroupId(String) - Method in class io.smallrye.reactive.messaging.amqp.AmqpMessageBuilder
- withGroupId(String) - Method in class io.smallrye.reactive.messaging.amqp.OutgoingAmqpMetadata.OutgoingAmqpMetadataBuilder
- 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.http.HttpMessage.HttpMessageBuilder
- withHeader(String, String) - Method in class io.smallrye.reactive.messaging.http.HttpResponseMetadata.HttpResponseMetadataBuilder
- 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.
- withHeader(String, List<String>) - Method in class io.smallrye.reactive.messaging.http.HttpMessage.HttpMessageBuilder
- withHeaders(List<RecordHeader>) - Method in class io.smallrye.reactive.messaging.kafka.OutgoingKafkaRecordMetadata.OutgoingKafkaRecordMetadataBuilder
- withHeaders(Map<String, List<String>>) - Method in class io.smallrye.reactive.messaging.http.HttpMessage.HttpMessageBuilder
- withHeaders(Map<String, List<String>>) - Method in class io.smallrye.reactive.messaging.http.HttpResponseMetadata.HttpResponseMetadataBuilder
- withHeaders(Headers) - Method in class io.smallrye.reactive.messaging.kafka.OutgoingKafkaRecordMetadata.OutgoingKafkaRecordMetadataBuilder
- withId(String) - Method in class io.smallrye.reactive.messaging.amqp.AmqpMessageBuilder
- withId(String) - Method in class io.smallrye.reactive.messaging.amqp.OutgoingAmqpMetadata.OutgoingAmqpMetadataBuilder
- withId(String) - Method in class io.smallrye.reactive.messaging.cloudevents.CloudEventMessageBuilder
- withInstantAsBody(Instant) - Method in class io.smallrye.reactive.messaging.amqp.AmqpMessageBuilder
- withIntegerAsBody(int) - Method in class io.smallrye.reactive.messaging.amqp.AmqpMessageBuilder
- withJsonArrayAsBody(JsonArray) - Method in class io.smallrye.reactive.messaging.amqp.AmqpMessageBuilder
- withJsonObjectAsBody(JsonObject) - Method in class io.smallrye.reactive.messaging.amqp.AmqpMessageBuilder
- withKey(K) - Method in class io.smallrye.reactive.messaging.kafka.OutgoingKafkaRecordMetadata.OutgoingKafkaRecordMetadataBuilder
- withLongAsBody(long) - Method in class io.smallrye.reactive.messaging.amqp.AmqpMessageBuilder
- withMetadata(Iterable<Object>) - Method in class io.smallrye.reactive.messaging.kafka.OutgoingKafkaRecord
- withMetadata(Iterable<Object>) - Method in interface org.eclipse.microprofile.reactive.messaging.Message
-
Creates a new instance of
Message
with the specified metadata. - withMetadata(Metadata) - Method in class io.smallrye.reactive.messaging.kafka.OutgoingKafkaRecord
- withMetadata(Metadata) - Method in interface org.eclipse.microprofile.reactive.messaging.Message
-
Creates a new instance of
Message
with the specified metadata. - withMethod(String) - Method in class io.smallrye.reactive.messaging.http.HttpMessage.HttpMessageBuilder
- withMethod(String) - Method in class io.smallrye.reactive.messaging.http.HttpResponseMetadata.HttpResponseMetadataBuilder
- without(Class<?>) - Method in class org.eclipse.microprofile.reactive.messaging.Metadata
-
Creates a new instance of
Metadata
with the current entries, minus the entry associated with the given class. - without(String) - Method in class io.smallrye.reactive.messaging.jms.JmsPropertiesBuilder
- withoutHeader(String) - Method in class io.smallrye.reactive.messaging.http.HttpResponseMetadata.HttpResponseMetadataBuilder
- withoutQueryParameter(String) - Method in class io.smallrye.reactive.messaging.http.HttpResponseMetadata.HttpResponseMetadataBuilder
- withPartition(int) - Method in class io.smallrye.reactive.messaging.kafka.OutgoingKafkaRecordMetadata.OutgoingKafkaRecordMetadataBuilder
- withPayload(P) - Method in class io.smallrye.reactive.messaging.kafka.OutgoingKafkaRecord
- withPayload(P) - Method in interface org.eclipse.microprofile.reactive.messaging.Message
-
Creates a new instance of
Message
with the specified payload. - withPayload(T) - Method in class io.smallrye.reactive.messaging.http.HttpMessage.HttpMessageBuilder
- withPriority(int) - Method in class io.smallrye.reactive.messaging.amqp.OutgoingAmqpMetadata.OutgoingAmqpMetadataBuilder
- withPriority(short) - Method in class io.smallrye.reactive.messaging.amqp.AmqpMessageBuilder
- withProperties(JmsProperties) - Method in class io.smallrye.reactive.messaging.jms.OutgoingJmsMessageMetadata.OutgoingJmsMessageMetadataBuilder
- withProperties(JsonObject) - Method in class io.smallrye.reactive.messaging.amqp.OutgoingAmqpMetadata.OutgoingAmqpMetadataBuilder
- withQueryParameter(String, String) - Method in class io.smallrye.reactive.messaging.http.HttpMessage.HttpMessageBuilder
- withQueryParameter(String, String) - Method in class io.smallrye.reactive.messaging.http.HttpResponseMetadata.HttpResponseMetadataBuilder
- withQueryParameter(String, List<String>) - Method in class io.smallrye.reactive.messaging.http.HttpMessage.HttpMessageBuilder
- withQueryParameter(Map<String, List<String>>) - Method in class io.smallrye.reactive.messaging.http.HttpResponseMetadata.HttpResponseMetadataBuilder
- withReplyTo(String) - Method in class io.smallrye.reactive.messaging.amqp.AmqpMessageBuilder
- withReplyTo(Destination) - Method in class io.smallrye.reactive.messaging.jms.OutgoingJmsMessageMetadata.OutgoingJmsMessageMetadataBuilder
- withReplyToGroupId(String) - Method in class io.smallrye.reactive.messaging.amqp.AmqpMessageBuilder
- withShortAsBody(short) - Method in class io.smallrye.reactive.messaging.amqp.AmqpMessageBuilder
- withSource(URI) - Method in class io.smallrye.reactive.messaging.cloudevents.CloudEventMessageBuilder
- withSubject(String) - Method in class io.smallrye.reactive.messaging.amqp.AmqpMessageBuilder
- withSubject(String) - Method in class io.smallrye.reactive.messaging.amqp.OutgoingAmqpMetadata.OutgoingAmqpMetadataBuilder
- withSubject(String) - Method in class io.smallrye.reactive.messaging.cloudevents.CloudEventMessageBuilder
- withSymbolAsBody(String) - Method in class io.smallrye.reactive.messaging.amqp.AmqpMessageBuilder
- withTime(ZonedDateTime) - Method in class io.smallrye.reactive.messaging.cloudevents.CloudEventMessageBuilder
- withTimestamp(Instant) - Method in class io.smallrye.reactive.messaging.kafka.OutgoingKafkaRecordMetadata.OutgoingKafkaRecordMetadataBuilder
- withTopic(String) - Method in class io.smallrye.reactive.messaging.kafka.OutgoingKafkaRecordMetadata.OutgoingKafkaRecordMetadataBuilder
- withTtl(long) - Method in class io.smallrye.reactive.messaging.amqp.AmqpMessageBuilder
- withTtl(long) - Method in class io.smallrye.reactive.messaging.amqp.OutgoingAmqpMetadata.OutgoingAmqpMetadataBuilder
- withType(String) - Method in class io.smallrye.reactive.messaging.cloudevents.CloudEventMessageBuilder
- withType(String) - Method in class io.smallrye.reactive.messaging.jms.OutgoingJmsMessageMetadata.OutgoingJmsMessageMetadataBuilder
- withUrl(String) - Method in class io.smallrye.reactive.messaging.http.HttpMessage.HttpMessageBuilder
- withUrl(String) - Method in class io.smallrye.reactive.messaging.http.HttpResponseMetadata.HttpResponseMetadataBuilder
- withUuidAsBody(UUID) - Method in class io.smallrye.reactive.messaging.amqp.AmqpMessageBuilder
- workerPoolRegistry - Variable in class io.smallrye.reactive.messaging.AbstractMediator
- WorkerPoolRegistry - Class in io.smallrye.reactive.messaging.connectors
- WorkerPoolRegistry() - Constructor for class io.smallrye.reactive.messaging.connectors.WorkerPoolRegistry
- wrap(JmsTask) - Static method in interface io.smallrye.reactive.messaging.jms.impl.JmsTask
- wrap(Callable<R>) - Static method in class io.smallrye.reactive.messaging.jms.impl.Wrap
- Wrap - Class in io.smallrye.reactive.messaging.jms.impl
All Classes All Packages