Uses of Interface
org.eclipse.microprofile.reactive.messaging.Message
-
-
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 inbound
Methods in inbound with parameters of type Message Modifier and Type Method Description CompletionStage<Void>KafkaPriceMessageConsumer. consume(Message<Double> price) -
Uses of Message in io.smallrye.reactive.messaging
Methods in io.smallrye.reactive.messaging with type parameters of type Message Modifier and Type Method Description <M extends Message<? extends T>>
voidMutinyEmitter. send(M msg)Sends a message to the channel.Methods in io.smallrye.reactive.messaging that return Message Modifier and Type Method Description Message<?>MessageConverter. convert(Message<?> in, Type target)Converts the given messageininto aMessage<T>.Message<?>MessageConverter.IdentityConverter. convert(Message<?> in, Type target)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. convert(org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder<? extends Message<?>> upstream)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 CompletionStage<Message<?>>AbstractMediator. handlePreProcessingAck(Message<?> message)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 booleanMessageConverter. canConvert(Message<?> in, Type target)Checks whether this instance of converter can convert the given messageininto aMessage<T>withTbeing the type represented bytarget.booleanMessageConverter.IdentityConverter. canConvert(Message<?> in, Type target)Message<?>MessageConverter. convert(Message<?> in, Type target)Converts the given messageininto aMessage<T>.Message<?>MessageConverter.IdentityConverter. convert(Message<?> in, Type target)static Optional<TracingMetadata>TracingMetadata. fromMessage(Message<?> message)protected CompletionStage<Message<?>>AbstractMediator. getAckOrCompletion(Message<?> message)protected CompletionStage<Message<?>>AbstractMediator. handlePreProcessingAck(Message<?> message)Method parameters in io.smallrye.reactive.messaging with type arguments of type Message Modifier and Type Method Description voidAbstractMediator. connectToUpstream(org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder<? extends Message<?>> publisher)voidProcessorMediator. connectToUpstream(org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder<? extends Message<?>> publisher)voidStreamTransformerMediator. connectToUpstream(org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder<? extends Message<?>> publisher)voidSubscriberMediator. connectToUpstream(org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder<? extends Message<?>> publisher)org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder<? extends Message<?>>AbstractMediator. convert(org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder<? extends Message<?>> upstream)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 classAmqpMessage<T>classOutgoingAmqpMessage<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)Methods in io.smallrye.reactive.messaging.amqp with parameters of type Message Modifier and Type Method Description voidAmqpCreditBasedSender. onNext(Message<?> message)Method parameters in io.smallrye.reactive.messaging.amqp with type arguments of type Message Modifier and Type Method Description voidAmqpCreditBasedSender. subscribe(org.reactivestreams.Subscriber<? super Message<?>> subscriber) -
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 classSnsMessageImplementation ofMessagefor 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 classCamelMessage<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 interfaceCloudEventMessage<T>Message extending Cloud Events.Classes in io.smallrye.reactive.messaging.cloudevents that implement Message Modifier and Type Class Description classDefaultCloudEventMessage<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 classEventBusMessage<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
Fields in io.smallrye.reactive.messaging.extension with type parameters of type Message Modifier and Type Field Description protected AtomicReference<io.smallrye.mutiny.subscription.MultiEmitter<? super Message<? extends T>>>AbstractEmitter. internalprotected io.smallrye.mutiny.Multi<Message<? extends T>>AbstractEmitter. publisherMethods 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)<M extends Message<? extends T>>
voidMutinyEmitterImpl. 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>>AbstractEmitter. getPublisher()Methods in io.smallrye.reactive.messaging.extension with parameters of type Message Modifier and Type Method Description protected voidAbstractEmitter. emit(Message<? extends T> message) -
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 classPubSubMessageMethods 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 voidPubSubSource. accept(io.smallrye.mutiny.subscription.MultiEmitter<? super Message<?>> emitter)voidPubSubManager. 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.helpers
Methods in io.smallrye.reactive.messaging.helpers that return types with arguments of type Message Modifier and Type Method Description static org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder<? extends Message<?>>BroadcastHelper. broadcastPublisher(org.reactivestreams.Publisher<? extends Message<?>> publisher, int numberOfSubscriberBeforeConnecting)Wraps an existingPublisherfor broadcasting.Method parameters in io.smallrye.reactive.messaging.helpers with type arguments of type Message Modifier and Type Method Description static org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder<? extends Message<?>>BroadcastHelper. broadcastPublisher(org.reactivestreams.Publisher<? extends Message<?>> publisher, int numberOfSubscriberBeforeConnecting)Wraps an existingPublisherfor broadcasting. -
Uses of Message in io.smallrye.reactive.messaging.http
Classes in io.smallrye.reactive.messaging.http that implement Message Modifier and Type Class Description classHttpMessage<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 classIncomingJmsMessage<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 interfaceKafkaMessage<K,T>Deprecated.UseinsteadinterfaceKafkaRecord<K,T>Classes in io.smallrye.reactive.messaging.kafka that implement Message Modifier and Type Class Description classIncomingKafkaRecord<K,T>classOutgoingKafkaRecord<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>KafkaRecord. from(Message<T> message)static <K,T>
OutgoingKafkaRecord<K,T>OutgoingKafkaRecord. from(Message<T> message) -
Uses of Message in io.smallrye.reactive.messaging.kafka.converters
Methods in io.smallrye.reactive.messaging.kafka.converters that return Message Modifier and Type Method Description Message<?>ConsumerRecordConverter. convert(Message<?> in, Type target)Message<?>RecordConverter. convert(Message<?> in, Type target)Methods in io.smallrye.reactive.messaging.kafka.converters with parameters of type Message Modifier and Type Method Description booleanConsumerRecordConverter. canConvert(Message<?> in, Type target)booleanRecordConverter. canConvert(Message<?> in, Type target)Message<?>ConsumerRecordConverter. convert(Message<?> in, Type target)Message<?>RecordConverter. convert(Message<?> in, Type target) -
Uses of Message in io.smallrye.reactive.messaging.kafka.i18n
Methods in io.smallrye.reactive.messaging.kafka.i18n with parameters of type Message Modifier and Type Method Description voidKafkaLogging_$logger. nackingMessage(Message message, String topic, Throwable t)voidKafkaLogging. nackingMessage(Message message, String topic, Throwable t)voidKafkaLogging_$logger. sendingMessageToTopic(Message message, String topic)voidKafkaLogging. sendingMessageToTopic(Message message, String topic)voidKafkaLogging_$logger. successfullyToTopic(Message message, String topic)voidKafkaLogging. successfullyToTopic(Message message, String topic) -
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() -
Uses of Message in io.smallrye.reactive.messaging.kafka.impl.ce
Methods in io.smallrye.reactive.messaging.kafka.impl.ce with parameters of type Message Modifier and Type Method Description static org.apache.kafka.clients.producer.ProducerRecord<?,?>KafkaCloudEventHelper. createBinaryRecord(Message<?> message, String topic, OutgoingKafkaRecordMetadata<?> metadata, OutgoingCloudEventMetadata<?> ceMetadata, KafkaConnectorOutgoingConfiguration configuration)static org.apache.kafka.clients.producer.ProducerRecord<?,?>KafkaCloudEventHelper. createStructuredRecord(Message<?> message, String topic, OutgoingKafkaRecordMetadata<?> metadata, OutgoingCloudEventMetadata<?> ceMetadata, KafkaConnectorOutgoingConfiguration configuration) -
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 interfaceMqttMessage<T>Classes in io.smallrye.reactive.messaging.mqtt that implement Message Modifier and Type Class Description classReceivingMqttMessageclassSendingMqttMessage<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 classMqttMessageMethods 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 message 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 ofMessagewith 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, Iterable<Object> metadata, Supplier<CompletionStage<Void>> ack, Function<Throwable,CompletionStage<Void>> nack)Create a message with the given payload, metadata and ack and nack functions.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, Supplier<CompletionStage<Void>> ack, Function<Throwable,CompletionStage<Void>> nack)Create a message with the given payload, ack and nack functions.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, Metadata metadata, Supplier<CompletionStage<Void>> ack, Function<Throwable,CompletionStage<Void>> nack)Create a message with the given payload, metadata and ack and nack functions.default Message<T>Message. withAck(Supplier<CompletionStage<Void>> supplier)Creates a new instance ofMessagewith the given acknowledgement supplier.default Message<T>Message. withMetadata(Iterable<Object> metadata)Creates a new instance ofMessagewith the specified metadata.default Message<T>Message. withMetadata(Metadata metadata)Creates a new instance ofMessagewith the specified metadata.default Message<T>Message. withNack(Function<Throwable,CompletionStage<Void>> nack)Creates a new instance ofMessagewith the given negative-acknowledgement function.default <P> Message<P>Message. withPayload(P payload)Creates a new instance ofMessagewith 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. -
Uses of Message in outbound
Methods in outbound that return types with arguments of type Message Modifier and Type Method Description io.smallrye.mutiny.Multi<Message<Double>>KafkaPriceMessageProducer. generate()
-