Uses of Interface
org.eclipse.microprofile.reactive.messaging.Message
-
Packages that use Message Package Description awssns io.smallrye.reactive.messaging io.smallrye.reactive.messaging.amqp io.smallrye.reactive.messaging.aws.sns io.smallrye.reactive.messaging.camel io.smallrye.reactive.messaging.cloudevents io.smallrye.reactive.messaging.connectors io.smallrye.reactive.messaging.eventbus io.smallrye.reactive.messaging.extension io.smallrye.reactive.messaging.gcp.pubsub io.smallrye.reactive.messaging.http io.smallrye.reactive.messaging.impl io.smallrye.reactive.messaging.jms io.smallrye.reactive.messaging.kafka io.smallrye.reactive.messaging.kafka.impl io.smallrye.reactive.messaging.metrics io.smallrye.reactive.messaging.mqtt io.smallrye.reactive.messaging.mqtt.server org.eclipse.microprofile.reactive.messaging IMPORTANT This package is a copy from the original package from the specification.org.eclipse.microprofile.reactive.messaging.spi The MicroProfile Reactive Messaging API Connector SPI -
-
Uses of Message in awssns
Methods in awssns with parameters of type Message Modifier and Type Method Description CompletionStage<Void>
Receiver. consume(Message<String> message)
-
Uses of Message in io.smallrye.reactive.messaging
Methods in io.smallrye.reactive.messaging that return types with arguments of type Message Modifier and Type Method Description org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder<? extends Message<?>>
AbstractMediator. decorate(org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder<? extends Message<?>> input)
org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder<? extends Message<?>>
PublisherDecorator. decorate(org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder<? extends Message<?>> publisher, String channelName)
Decorate a publisherprotected CompletionStage<Message<?>>
AbstractMediator. getAckOrCompletion(Message<?> message)
org.eclipse.microprofile.reactive.streams.operators.SubscriberBuilder<Message<?>,Void>
AbstractMediator. getComputedSubscriber()
org.eclipse.microprofile.reactive.streams.operators.SubscriberBuilder<Message<?>,Void>
SubscriberMediator. getComputedSubscriber()
List<org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder<? extends Message<?>>>
ChannelRegistry. getPublishers(String name)
org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder<? extends Message<?>>
AbstractMediator. getStream()
org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder<? extends Message<?>>
ProcessorMediator. getStream()
org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder<? extends Message<?>>
PublisherMediator. getStream()
org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder<? extends Message<?>>
StreamTransformerMediator. getStream()
List<org.eclipse.microprofile.reactive.streams.operators.SubscriberBuilder<? extends Message<?>,Void>>
ChannelRegistry. getSubscribers(String name)
protected Function<Message<?>,? extends CompletionStage<? extends Message<?>>>
AbstractMediator. managePreProcessingAck()
protected Function<Message<?>,? extends CompletionStage<? extends Message<?>>>
AbstractMediator. managePreProcessingAck()
org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder<? extends Message<?>>
ChannelRegistry. register(String name, org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder<? extends Message<?>> stream)
org.eclipse.microprofile.reactive.streams.operators.SubscriberBuilder<? extends Message<?>,Void>
ChannelRegistry. register(String name, org.eclipse.microprofile.reactive.streams.operators.SubscriberBuilder<? extends Message<?>,Void> subscriber)
Methods in io.smallrye.reactive.messaging with parameters of type Message Modifier and Type Method Description protected CompletionStage<Message<?>>
AbstractMediator. getAckOrCompletion(Message<?> message)
Method parameters in io.smallrye.reactive.messaging with type arguments of type Message Modifier and Type Method Description void
AbstractMediator. connectToUpstream(org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder<? extends Message<?>> publisher)
void
ProcessorMediator. connectToUpstream(org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder<? extends Message<?>> publisher)
void
StreamTransformerMediator. connectToUpstream(org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder<? extends Message<?>> publisher)
void
SubscriberMediator. connectToUpstream(org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder<? extends Message<?>> publisher)
org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder<? extends Message<?>>
AbstractMediator. decorate(org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder<? extends Message<?>> input)
org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder<? extends Message<?>>
PublisherDecorator. decorate(org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder<? extends Message<?>> publisher, String channelName)
Decorate a publisherorg.eclipse.microprofile.reactive.streams.operators.PublisherBuilder<? extends Message<?>>
ChannelRegistry. register(String name, org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder<? extends Message<?>> stream)
org.eclipse.microprofile.reactive.streams.operators.SubscriberBuilder<? extends Message<?>,Void>
ChannelRegistry. register(String name, org.eclipse.microprofile.reactive.streams.operators.SubscriberBuilder<? extends Message<?>,Void> subscriber)
-
Uses of Message in io.smallrye.reactive.messaging.amqp
Classes in io.smallrye.reactive.messaging.amqp that implement Message Modifier and Type Class Description class
AmqpMessage<T>
class
OutgoingAmqpMessage<T>
Methods in io.smallrye.reactive.messaging.amqp that return types with arguments of type Message Modifier and Type Method Description org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder<? extends Message<?>>
AmqpConnector. getPublisherBuilder(org.eclipse.microprofile.config.Config config)
org.eclipse.microprofile.reactive.streams.operators.SubscriberBuilder<? extends Message<?>,Void>
AmqpConnector. getSubscriberBuilder(org.eclipse.microprofile.config.Config config)
-
Uses of Message in io.smallrye.reactive.messaging.aws.sns
Classes in io.smallrye.reactive.messaging.aws.sns that implement Message Modifier and Type Class Description class
SnsMessage
Implementation ofMessage
for SNS.Methods in io.smallrye.reactive.messaging.aws.sns that return types with arguments of type Message Modifier and Type Method Description org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder<? extends Message<?>>
SnsConnector. getPublisherBuilder(org.eclipse.microprofile.config.Config config)
org.eclipse.microprofile.reactive.streams.operators.SubscriberBuilder<? extends Message<?>,Void>
SnsConnector. getSubscriberBuilder(org.eclipse.microprofile.config.Config config)
-
Uses of Message in io.smallrye.reactive.messaging.camel
Classes in io.smallrye.reactive.messaging.camel that implement Message Modifier and Type Class Description class
CamelMessage<T>
Methods in io.smallrye.reactive.messaging.camel that return types with arguments of type Message Modifier and Type Method Description org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder<? extends Message<?>>
CamelConnector. getPublisherBuilder(org.eclipse.microprofile.config.Config config)
org.eclipse.microprofile.reactive.streams.operators.SubscriberBuilder<? extends Message<?>,Void>
CamelConnector. getSubscriberBuilder(org.eclipse.microprofile.config.Config config)
-
Uses of Message in io.smallrye.reactive.messaging.cloudevents
Subinterfaces of Message in io.smallrye.reactive.messaging.cloudevents Modifier and Type Interface Description interface
CloudEventMessage<T>
Message extending Cloud Events.Classes in io.smallrye.reactive.messaging.cloudevents that implement Message Modifier and Type Class Description class
DefaultCloudEventMessage<T>
Methods in io.smallrye.reactive.messaging.cloudevents with parameters of type Message Modifier and Type Method Description static <T> CloudEventMessageBuilder<T>
CloudEventMessageBuilder. from(Message<T> message)
-
Uses of Message in io.smallrye.reactive.messaging.connectors
Methods in io.smallrye.reactive.messaging.connectors that return types with arguments of type Message Modifier and Type Method Description org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder<? extends Message<?>>
InMemoryConnector. getPublisherBuilder(org.eclipse.microprofile.config.Config config)
org.eclipse.microprofile.reactive.streams.operators.SubscriberBuilder<? extends Message<?>,Void>
InMemoryConnector. getSubscriberBuilder(org.eclipse.microprofile.config.Config config)
List<? extends Message<T>>
InMemorySink. received()
-
Uses of Message in io.smallrye.reactive.messaging.eventbus
Classes in io.smallrye.reactive.messaging.eventbus that implement Message Modifier and Type Class Description class
EventBusMessage<T>
Methods in io.smallrye.reactive.messaging.eventbus that return types with arguments of type Message Modifier and Type Method Description org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder<? extends Message<?>>
VertxEventBusConnector. getPublisherBuilder(org.eclipse.microprofile.config.Config config)
org.eclipse.microprofile.reactive.streams.operators.SubscriberBuilder<? extends Message<?>,Void>
VertxEventBusConnector. getSubscriberBuilder(org.eclipse.microprofile.config.Config config)
-
Uses of Message in io.smallrye.reactive.messaging.extension
Methods in io.smallrye.reactive.messaging.extension with type parameters of type Message Modifier and Type Method Description <M extends Message<? extends T>>
voidEmitterImpl. send(M msg)
Methods in io.smallrye.reactive.messaging.extension that return types with arguments of type Message Modifier and Type Method Description org.reactivestreams.Publisher<Message<? extends T>>
EmitterImpl. getPublisher()
-
Uses of Message in io.smallrye.reactive.messaging.gcp.pubsub
Classes in io.smallrye.reactive.messaging.gcp.pubsub that implement Message Modifier and Type Class Description class
PubSubMessage
Methods in io.smallrye.reactive.messaging.gcp.pubsub that return types with arguments of type Message Modifier and Type Method Description org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder<? extends Message<?>>
PubSubConnector. getPublisherBuilder(org.eclipse.microprofile.config.Config config)
org.eclipse.microprofile.reactive.streams.operators.SubscriberBuilder<? extends Message<?>,Void>
PubSubConnector. getSubscriberBuilder(org.eclipse.microprofile.config.Config config)
Method parameters in io.smallrye.reactive.messaging.gcp.pubsub with type arguments of type Message Modifier and Type Method Description void
PubSubSource. accept(io.smallrye.mutiny.subscription.MultiEmitter<? super Message<?>> emitter)
void
PubSubManager. subscriber(PubSubConfig config, io.smallrye.mutiny.subscription.MultiEmitter<? super Message<?>> emitter)
Constructor parameters in io.smallrye.reactive.messaging.gcp.pubsub with type arguments of type Message Constructor Description PubSubMessageReceiver(io.smallrye.mutiny.subscription.MultiEmitter<? super Message<?>> emitter)
-
Uses of Message in io.smallrye.reactive.messaging.http
Classes in io.smallrye.reactive.messaging.http that implement Message Modifier and Type Class Description class
HttpMessage<T>
Methods in io.smallrye.reactive.messaging.http that return types with arguments of type Message Modifier and Type Method Description org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder<? extends Message<?>>
HttpConnector. getPublisherBuilder(org.eclipse.microprofile.config.Config config)
org.eclipse.microprofile.reactive.streams.operators.SubscriberBuilder<? extends Message<?>,Void>
HttpConnector. getSubscriberBuilder(org.eclipse.microprofile.config.Config config)
-
Uses of Message in io.smallrye.reactive.messaging.impl
Methods in io.smallrye.reactive.messaging.impl that return types with arguments of type Message Modifier and Type Method Description List<org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder<? extends Message<?>>>
InternalChannelRegistry. getPublishers(String name)
List<org.eclipse.microprofile.reactive.streams.operators.SubscriberBuilder<? extends Message<?>,Void>>
InternalChannelRegistry. getSubscribers(String name)
org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder<? extends Message<?>>
InternalChannelRegistry. register(String name, org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder<? extends Message<?>> stream)
org.eclipse.microprofile.reactive.streams.operators.SubscriberBuilder<? extends Message<?>,Void>
InternalChannelRegistry. register(String name, org.eclipse.microprofile.reactive.streams.operators.SubscriberBuilder<? extends Message<?>,Void> subscriber)
Method parameters in io.smallrye.reactive.messaging.impl with type arguments of type Message Modifier and Type Method Description org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder<? extends Message<?>>
InternalChannelRegistry. register(String name, org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder<? extends Message<?>> stream)
org.eclipse.microprofile.reactive.streams.operators.SubscriberBuilder<? extends Message<?>,Void>
InternalChannelRegistry. register(String name, org.eclipse.microprofile.reactive.streams.operators.SubscriberBuilder<? extends Message<?>,Void> subscriber)
-
Uses of Message in io.smallrye.reactive.messaging.jms
Classes in io.smallrye.reactive.messaging.jms that implement Message Modifier and Type Class Description class
IncomingJmsMessage<T>
Methods in io.smallrye.reactive.messaging.jms that return types with arguments of type Message Modifier and Type Method Description org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder<? extends Message<?>>
JmsConnector. getPublisherBuilder(org.eclipse.microprofile.config.Config config)
org.eclipse.microprofile.reactive.streams.operators.SubscriberBuilder<? extends Message<?>,Void>
JmsConnector. getSubscriberBuilder(org.eclipse.microprofile.config.Config config)
-
Uses of Message in io.smallrye.reactive.messaging.kafka
Subinterfaces of Message in io.smallrye.reactive.messaging.kafka Modifier and Type Interface Description interface
KafkaMessage<K,T>
Deprecated.Useinstead
interface
KafkaRecord<K,T>
Classes in io.smallrye.reactive.messaging.kafka that implement Message Modifier and Type Class Description class
IncomingKafkaRecord<K,T>
class
OutgoingKafkaRecord<K,T>
Methods in io.smallrye.reactive.messaging.kafka that return types with arguments of type Message Modifier and Type Method Description org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder<? extends Message<?>>
KafkaConnector. getPublisherBuilder(org.eclipse.microprofile.config.Config config)
org.eclipse.microprofile.reactive.streams.operators.SubscriberBuilder<? extends Message<?>,Void>
KafkaConnector. getSubscriberBuilder(org.eclipse.microprofile.config.Config config)
Methods in io.smallrye.reactive.messaging.kafka with parameters of type Message Modifier and Type Method Description static <K,T>
OutgoingKafkaRecord<K,T>OutgoingKafkaRecord. from(Message<T> message)
-
Uses of Message in io.smallrye.reactive.messaging.kafka.impl
Methods in io.smallrye.reactive.messaging.kafka.impl that return types with arguments of type Message Modifier and Type Method Description org.eclipse.microprofile.reactive.streams.operators.SubscriberBuilder<? extends Message<?>,Void>
KafkaSink. getSink()
org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder<? extends Message<?>>
KafkaSource. getSource()
-
Uses of Message in io.smallrye.reactive.messaging.metrics
Methods in io.smallrye.reactive.messaging.metrics that return types with arguments of type Message Modifier and Type Method Description org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder<? extends Message<?>>
MetricDecorator. decorate(org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder<? extends Message<?>> publisher, String channelName)
Method parameters in io.smallrye.reactive.messaging.metrics with type arguments of type Message Modifier and Type Method Description org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder<? extends Message<?>>
MetricDecorator. decorate(org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder<? extends Message<?>> publisher, String channelName)
-
Uses of Message in io.smallrye.reactive.messaging.mqtt
Subinterfaces of Message in io.smallrye.reactive.messaging.mqtt Modifier and Type Interface Description interface
MqttMessage<T>
Classes in io.smallrye.reactive.messaging.mqtt that implement Message Modifier and Type Class Description class
ReceivingMqttMessage
class
SendingMqttMessage<T>
Methods in io.smallrye.reactive.messaging.mqtt that return types with arguments of type Message Modifier and Type Method Description org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder<? extends Message<?>>
MqttConnector. getPublisherBuilder(org.eclipse.microprofile.config.Config config)
org.eclipse.microprofile.reactive.streams.operators.SubscriberBuilder<? extends Message<?>,Void>
MqttSink. getSink()
org.eclipse.microprofile.reactive.streams.operators.SubscriberBuilder<? extends Message<?>,Void>
MqttConnector. getSubscriberBuilder(org.eclipse.microprofile.config.Config config)
-
Uses of Message in io.smallrye.reactive.messaging.mqtt.server
Classes in io.smallrye.reactive.messaging.mqtt.server that implement Message Modifier and Type Class Description class
MqttMessage
Methods in io.smallrye.reactive.messaging.mqtt.server that return types with arguments of type Message Modifier and Type Method Description org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder<? extends Message<?>>
MqttServerConnector. getPublisherBuilder(org.eclipse.microprofile.config.Config config)
-
Uses of Message in org.eclipse.microprofile.reactive.messaging
Methods in org.eclipse.microprofile.reactive.messaging with type parameters of type Message Modifier and Type Method Description <M extends Message<? extends T>>
voidEmitter. send(M msg)
Sends a payload to the channel.Methods in org.eclipse.microprofile.reactive.messaging that return Message Modifier and Type Method Description default Message<T>
Message. addMetadata(Object metadata)
Creates a new instance ofMessage
with the current metadata, plus the given one.static <T> Message<T>
Message. of(T payload)
Create a message with the given payload.static <T> Message<T>
Message. of(T payload, Iterable<Object> metadata)
Create a message with the given payload and metadata.static <T> Message<T>
Message. of(T payload, Iterable<Object> metadata, Supplier<CompletionStage<Void>> ack)
Create a message with the given payload, metadata and ack function.static <T> Message<T>
Message. of(T payload, Supplier<CompletionStage<Void>> ack)
Create a message with the given payload and ack function.static <T> Message<T>
Message. of(T payload, Metadata metadata)
Create a message with the given payload and metadata.static <T> Message<T>
Message. of(T payload, Metadata metadata, Supplier<CompletionStage<Void>> ack)
Create a message with the given payload, metadata and ack function.default Message<T>
Message. withAck(Supplier<CompletionStage<Void>> supplier)
Creates a new instance ofMessage
with the given acknowledgement supplier.default Message<T>
Message. withMetadata(Iterable<Object> metadata)
Creates a new instance ofMessage
with the specified metadata.default Message<T>
Message. withMetadata(Metadata metadata)
Creates a new instance ofMessage
with the specified metadata.default <P> Message<P>
Message. withPayload(P payload)
Creates a new instance ofMessage
with the specified payload. -
Uses of Message in org.eclipse.microprofile.reactive.messaging.spi
Methods in org.eclipse.microprofile.reactive.messaging.spi that return types with arguments of type Message Modifier and Type Method Description org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder<? extends Message<?>>
IncomingConnectorFactory. getPublisherBuilder(org.eclipse.microprofile.config.Config config)
Creates a channel for the given configuration.org.eclipse.microprofile.reactive.streams.operators.SubscriberBuilder<? extends Message<?>,Void>
OutgoingConnectorFactory. getSubscriberBuilder(org.eclipse.microprofile.config.Config config)
Creates a channel for the given configuration.
-