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
|
Modifier and Type | Method and Description |
---|---|
CompletionStage<Void> |
Receiver.consume(Message<String> message) |
Modifier and Type | Method and 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 publisher
|
protected CompletionStage<Message<?>> |
AbstractMediator.getAckOrCompletion(Message<?> message) |
org.eclipse.microprofile.reactive.streams.operators.SubscriberBuilder<Message<?>,Void> |
SubscriberMediator.getComputedSubscriber() |
org.eclipse.microprofile.reactive.streams.operators.SubscriberBuilder<Message<?>,Void> |
AbstractMediator.getComputedSubscriber() |
List<org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder<? extends Message<?>>> |
ChannelRegistry.getPublishers(String name) |
org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder<? extends Message<?>> |
ProcessorMediator.getStream() |
org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder<? extends Message<?>> |
StreamTransformerMediator.getStream() |
org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder<? extends Message<?>> |
AbstractMediator.getStream() |
org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder<? extends Message<?>> |
PublisherMediator.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) |
Modifier and Type | Method and Description |
---|---|
protected CompletionStage<Message<?>> |
AbstractMediator.getAckOrCompletion(Message<?> message) |
Modifier and Type | Method and Description |
---|---|
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) |
void |
AbstractMediator.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 publisher
|
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) |
Modifier and Type | Class and Description |
---|---|
class |
AmqpMessage<T> |
class |
OutgoingAmqpMessage<T> |
Modifier and Type | Method and 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) |
Modifier and Type | Class and Description |
---|---|
class |
SnsMessage
Implementation of
Message for SNS. |
Modifier and Type | Method and 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) |
Modifier and Type | Class and Description |
---|---|
class |
CamelMessage<T> |
Modifier and Type | Method and 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) |
Modifier and Type | Interface and Description |
---|---|
interface |
CloudEventMessage<T>
Message extending Cloud Events.
|
Modifier and Type | Class and Description |
---|---|
class |
DefaultCloudEventMessage<T> |
Modifier and Type | Method and Description |
---|---|
static <T> CloudEventMessageBuilder<T> |
CloudEventMessageBuilder.from(Message<T> message) |
Modifier and Type | Method and 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() |
Modifier and Type | Class and Description |
---|---|
class |
EventBusMessage<T> |
Modifier and Type | Method and 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) |
Modifier and Type | Method and Description |
---|---|
<M extends Message<? extends T>> |
EmitterImpl.send(M msg) |
Modifier and Type | Method and Description |
---|---|
org.reactivestreams.Publisher<Message<? extends T>> |
EmitterImpl.getPublisher() |
Modifier and Type | Class and Description |
---|---|
class |
PubSubMessage |
Modifier and Type | Method and 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) |
Modifier and Type | Method and 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 and Description |
---|
PubSubMessageReceiver(io.smallrye.mutiny.subscription.MultiEmitter<? super Message<?>> emitter) |
Modifier and Type | Class and Description |
---|---|
class |
HttpMessage<T> |
Modifier and Type | Method and 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) |
Modifier and Type | Method and 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) |
Modifier and Type | Method and 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) |
Modifier and Type | Class and Description |
---|---|
class |
IncomingJmsMessage<T> |
Modifier and Type | Method and 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) |
Modifier and Type | Interface and Description |
---|---|
interface |
KafkaMessage<K,T>
Deprecated.
Use
instead |
interface |
KafkaRecord<K,T> |
Modifier and Type | Class and Description |
---|---|
class |
IncomingKafkaRecord<K,T> |
class |
OutgoingKafkaRecord<K,T> |
Modifier and Type | Method and 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) |
Modifier and Type | Method and Description |
---|---|
static <K,T> OutgoingKafkaRecord<K,T> |
OutgoingKafkaRecord.from(Message<T> message) |
Modifier and Type | Method and Description |
---|---|
org.eclipse.microprofile.reactive.streams.operators.SubscriberBuilder<? extends Message<?>,Void> |
KafkaSink.getSink() |
org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder<? extends Message<?>> |
KafkaSource.getSource() |
Modifier and Type | Method and Description |
---|---|
org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder<? extends Message<?>> |
MetricDecorator.decorate(org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder<? extends Message<?>> publisher,
String channelName) |
Modifier and Type | Method and Description |
---|---|
org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder<? extends Message<?>> |
MetricDecorator.decorate(org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder<? extends Message<?>> publisher,
String channelName) |
Modifier and Type | Interface and Description |
---|---|
interface |
MqttMessage<T> |
Modifier and Type | Class and Description |
---|---|
class |
ReceivingMqttMessage |
class |
SendingMqttMessage<T> |
Modifier and Type | Method and 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) |
Modifier and Type | Class and Description |
---|---|
class |
MqttMessage |
Modifier and Type | Method and Description |
---|---|
org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder<? extends Message<?>> |
MqttServerConnector.getPublisherBuilder(org.eclipse.microprofile.config.Config config) |
Modifier and Type | Method and Description |
---|---|
<M extends Message<? extends T>> |
Emitter.send(M msg)
Sends a payload to the channel.
|
Modifier and Type | Method and Description |
---|---|
default Message<T> |
Message.addMetadata(Object metadata)
Creates a new instance of
Message 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,
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.
|
static <T> Message<T> |
Message.of(T payload,
Supplier<CompletionStage<Void>> ack)
Create a message with the given payload and ack function.
|
default Message<T> |
Message.withAck(Supplier<CompletionStage<Void>> supplier)
Creates a new instance of
Message with the given acknowledgement supplier. |
default Message<T> |
Message.withMetadata(Iterable<Object> metadata)
Creates a new instance of
Message with the specified metadata. |
default Message<T> |
Message.withMetadata(Metadata metadata)
Creates a new instance of
Message with the specified metadata. |
default <P> Message<P> |
Message.withPayload(P payload)
Creates a new instance of
Message with the specified payload. |
Modifier and Type | Method and 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.
|
Copyright © 2018–2020 SmallRye. All rights reserved.