Uses of Interface
org.eclipse.microprofile.reactive.messaging.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 List<org.reactivestreams.Publisher<? extends Message<?>>>ChannelRegistry. getPublishers(String name)List<org.reactivestreams.Subscriber<? extends Message<?>>>ChannelRegistry. getSubscribers(String name)org.reactivestreams.Publisher<? extends Message<?>>ChannelRegistry. register(String name, org.reactivestreams.Publisher<? extends Message<?>> stream, boolean broadcast)org.reactivestreams.Subscriber<? extends Message<?>>ChannelRegistry. register(String name, org.reactivestreams.Subscriber<? extends Message<?>> subscriber, boolean merge)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)Method parameters in io.smallrye.reactive.messaging with type arguments of type Message Modifier and Type Method Description org.reactivestreams.Publisher<? extends Message<?>>ChannelRegistry. register(String name, org.reactivestreams.Publisher<? extends Message<?>> stream, boolean broadcast)org.reactivestreams.Subscriber<? extends Message<?>>ChannelRegistry. register(String name, org.reactivestreams.Subscriber<? extends Message<?>> subscriber, boolean merge) -
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.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.connector
Methods in io.smallrye.reactive.messaging.connector that return types with arguments of type Message Modifier and Type Method Description org.reactivestreams.Publisher<? extends Message<?>>InboundConnector. getPublisher(org.eclipse.microprofile.config.Config config)Creates a channel for the given configuration.org.reactivestreams.Subscriber<? extends Message<?>>OutboundConnector. getSubscriber(org.eclipse.microprofile.config.Config config)Creates a channel for the given configuration. -
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.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>interfaceKafkaRecordBatch<K,T>Represents a batch of Kafka records received by polling theKafkaConsumerThis type extends theMessage<List<T>>whereTis the type of records' payloads.Classes in io.smallrye.reactive.messaging.kafka that implement Message Modifier and Type Class Description classIncomingKafkaRecord<K,T>classIncomingKafkaRecordBatch<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.api
Methods in io.smallrye.reactive.messaging.kafka.api that return Message Modifier and Type Method Description static <T,K>
Message<T>KafkaMetadataUtil. writeOutgoingKafkaMetadata(Message<T> msg, OutgoingKafkaRecordMetadata<K> outgoingKafkaRecordMetadata)WriteOutgoingKafkaRecordMetadatato aMessage.Methods in io.smallrye.reactive.messaging.kafka.api with parameters of type Message Modifier and Type Method Description static Optional<IncomingKafkaRecordMetadata>KafkaMetadataUtil. readIncomingKafkaMetadata(Message<?> msg)ReadIncomingKafkaRecordMetadatafrom aMessage.static <T,K>
Message<T>KafkaMetadataUtil. writeOutgoingKafkaMetadata(Message<T> msg, OutgoingKafkaRecordMetadata<K> outgoingKafkaRecordMetadata)WriteOutgoingKafkaRecordMetadatato aMessage. -
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<?>ConsumerRecordsConverter. 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)booleanConsumerRecordsConverter. canConvert(Message<?> in, Type target)booleanRecordConverter. canConvert(Message<?> in, Type target)Message<?>ConsumerRecordConverter. convert(Message<?> in, Type target)Message<?>ConsumerRecordsConverter. 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.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.providers
Methods in io.smallrye.reactive.messaging.providers that return types with arguments of type Message Modifier and Type Method Description io.smallrye.mutiny.Multi<? extends Message<?>>AbstractMediator. convert(io.smallrye.mutiny.Multi<? extends Message<?>> upstream)io.smallrye.mutiny.Multi<? extends Message<?>>AbstractMediator. decorate(io.smallrye.mutiny.Multi<? extends Message<?>> input)io.smallrye.mutiny.Multi<? extends Message<?>>PublisherDecorator. decorate(io.smallrye.mutiny.Multi<? extends Message<?>> publisher, String channelName)Decorate a Multiprotected CompletionStage<Message<?>>AbstractMediator. getAckOrCompletion(Message<?> message)org.reactivestreams.Subscriber<Message<?>>AbstractMediator. getComputedSubscriber()org.reactivestreams.Subscriber<Message<?>>SubscriberMediator. getComputedSubscriber()io.smallrye.mutiny.Multi<? extends Message<?>>AbstractMediator. getStream()io.smallrye.mutiny.Multi<? extends Message<?>>ProcessorMediator. getStream()io.smallrye.mutiny.Multi<? extends Message<?>>PublisherMediator. getStream()io.smallrye.mutiny.Multi<? extends Message<?>>StreamTransformerMediator. getStream()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()Methods in io.smallrye.reactive.messaging.providers with parameters of type Message Modifier and Type Method Description protected CompletionStage<Message<?>>AbstractMediator. getAckOrCompletion(Message<?> message)protected CompletionStage<Message<?>>AbstractMediator. handlePreProcessingAck(Message<?> message)Method parameters in io.smallrye.reactive.messaging.providers with type arguments of type Message Modifier and Type Method Description voidAbstractMediator. connectToUpstream(io.smallrye.mutiny.Multi<? extends Message<?>> publisher)voidProcessorMediator. connectToUpstream(io.smallrye.mutiny.Multi<? extends Message<?>> publisher)voidStreamTransformerMediator. connectToUpstream(io.smallrye.mutiny.Multi<? extends Message<?>> publisher)voidSubscriberMediator. connectToUpstream(io.smallrye.mutiny.Multi<? extends Message<?>> publisher)io.smallrye.mutiny.Multi<? extends Message<?>>AbstractMediator. convert(io.smallrye.mutiny.Multi<? extends Message<?>> upstream)io.smallrye.mutiny.Multi<? extends Message<?>>AbstractMediator. decorate(io.smallrye.mutiny.Multi<? extends Message<?>> input)io.smallrye.mutiny.Multi<? extends Message<?>>PublisherDecorator. decorate(io.smallrye.mutiny.Multi<? extends Message<?>> publisher, String channelName)Decorate a Multi -
Uses of Message in io.smallrye.reactive.messaging.providers.connectors
Methods in io.smallrye.reactive.messaging.providers.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.providers.extension
Fields in io.smallrye.reactive.messaging.providers.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.providers.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.providers.extension that return types with arguments of type Message Modifier and Type Method Description org.reactivestreams.Publisher<Message<? extends T>>AbstractEmitter. getPublisher()protected io.smallrye.mutiny.subscription.MultiEmitter<? super Message<? extends T>>AbstractEmitter. verify()Methods in io.smallrye.reactive.messaging.providers.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.providers.helpers
Fields in io.smallrye.reactive.messaging.providers.helpers with type parameters of type Message Modifier and Type Field Description static org.reactivestreams.Subscriber<Message<?>>IgnoringSubscriber. INSTANCEMethods in io.smallrye.reactive.messaging.providers.helpers that return types with arguments of type Message Modifier and Type Method Description static io.smallrye.mutiny.Multi<? extends Message<?>>BroadcastHelper. broadcastPublisher(io.smallrye.mutiny.Multi<? extends Message<?>> publisher, int numberOfSubscriberBeforeConnecting)Wraps an existingPublisherfor broadcasting.static io.smallrye.mutiny.Multi<? extends Message<?>>ConverterUtils. convert(io.smallrye.mutiny.Multi<? extends Message<?>> upstream, javax.enterprise.inject.Instance<MessageConverter> converters, Type injectedPayloadType)static io.smallrye.mutiny.Multi<? extends Message<?>>MultiUtils. handlePreProcessingAcknowledgement(io.smallrye.mutiny.Multi<? extends Message<?>> multi, MediatorConfiguration configuration)Methods in io.smallrye.reactive.messaging.providers.helpers with parameters of type Message Modifier and Type Method Description voidIgnoringSubscriber. onNext(Message<?> message)Method parameters in io.smallrye.reactive.messaging.providers.helpers with type arguments of type Message Modifier and Type Method Description static io.smallrye.mutiny.Multi<? extends Message<?>>BroadcastHelper. broadcastPublisher(io.smallrye.mutiny.Multi<? extends Message<?>> publisher, int numberOfSubscriberBeforeConnecting)Wraps an existingPublisherfor broadcasting.static io.smallrye.mutiny.Multi<? extends Message<?>>ConverterUtils. convert(io.smallrye.mutiny.Multi<? extends Message<?>> upstream, javax.enterprise.inject.Instance<MessageConverter> converters, Type injectedPayloadType)static io.smallrye.mutiny.Multi<? extends Message<?>>MultiUtils. handlePreProcessingAcknowledgement(io.smallrye.mutiny.Multi<? extends Message<?>> multi, MediatorConfiguration configuration) -
Uses of Message in io.smallrye.reactive.messaging.providers.impl
Methods in io.smallrye.reactive.messaging.providers.impl that return types with arguments of type Message Modifier and Type Method Description List<org.reactivestreams.Publisher<? extends Message<?>>>InternalChannelRegistry. getPublishers(String name)List<org.reactivestreams.Subscriber<? extends Message<?>>>InternalChannelRegistry. getSubscribers(String name)org.reactivestreams.Publisher<? extends Message<?>>InternalChannelRegistry. register(String name, org.reactivestreams.Publisher<? extends Message<?>> stream, boolean broadcast)org.reactivestreams.Subscriber<? extends Message<?>>InternalChannelRegistry. register(String name, org.reactivestreams.Subscriber<? extends Message<?>> subscriber, boolean merge)Method parameters in io.smallrye.reactive.messaging.providers.impl with type arguments of type Message Modifier and Type Method Description org.reactivestreams.Publisher<? extends Message<?>>InternalChannelRegistry. register(String name, org.reactivestreams.Publisher<? extends Message<?>> stream, boolean broadcast)org.reactivestreams.Subscriber<? extends Message<?>>InternalChannelRegistry. register(String name, org.reactivestreams.Subscriber<? extends Message<?>> subscriber, boolean merge) -
Uses of Message in io.smallrye.reactive.messaging.providers.metrics
Methods in io.smallrye.reactive.messaging.providers.metrics that return types with arguments of type Message Modifier and Type Method Description io.smallrye.mutiny.Multi<? extends Message<?>>MetricDecorator. decorate(io.smallrye.mutiny.Multi<? extends Message<?>> publisher, String channelName)io.smallrye.mutiny.Multi<? extends Message<?>>MicrometerDecorator. decorate(io.smallrye.mutiny.Multi<? extends Message<?>> publisher, String channelName)Method parameters in io.smallrye.reactive.messaging.providers.metrics with type arguments of type Message Modifier and Type Method Description io.smallrye.mutiny.Multi<? extends Message<?>>MetricDecorator. decorate(io.smallrye.mutiny.Multi<? extends Message<?>> publisher, String channelName)io.smallrye.mutiny.Multi<? extends Message<?>>MicrometerDecorator. decorate(io.smallrye.mutiny.Multi<? extends Message<?>> publisher, String channelName) -
Uses of Message in io.smallrye.reactive.messaging.rabbitmq
Classes in io.smallrye.reactive.messaging.rabbitmq that implement Message Modifier and Type Class Description classIncomingRabbitMQMessage<T>An implementation ofMessagesuitable for incoming RabbitMQ messages.Methods in io.smallrye.reactive.messaging.rabbitmq that return types with arguments of type Message Modifier and Type Method Description org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder<? extends Message<?>>RabbitMQConnector. getPublisherBuilder(org.eclipse.microprofile.config.Config config)Creates a channel for the given configuration.org.eclipse.microprofile.reactive.streams.operators.SubscriberBuilder<? extends Message<?>,Void>RabbitMQConnector. getSubscriberBuilder(org.eclipse.microprofile.config.Config config)Creates a channel for the given configuration.Methods in io.smallrye.reactive.messaging.rabbitmq with parameters of type Message Modifier and Type Method Description static RabbitMQMessageConverter.OutgoingRabbitMQMessageRabbitMQMessageConverter. convert(Message<?> message, String exchange, String defaultRoutingKey, Optional<Long> defaultTtl, boolean isTracingEnabled, List<String> attributeHeaders)Converts the suppliedMessageto anRabbitMQMessageConverter.OutgoingRabbitMQMessage.voidRabbitMQMessageSender. onNext(Message<?> message)Data notification sent by thePublisherin response to requests toSubscription.request(long).Method parameters in io.smallrye.reactive.messaging.rabbitmq with type arguments of type Message Modifier and Type Method Description voidRabbitMQMessageSender. subscribe(org.reactivestreams.Subscriber<? super Message<?>> subscriber)RequestPublisherto start streaming data. -
Uses of Message in io.smallrye.reactive.messaging.rabbitmq.tracing
Methods in io.smallrye.reactive.messaging.rabbitmq.tracing that return Message Modifier and Type Method Description static <T> Message<T>TracingUtils. addIncomingTrace(IncomingRabbitMQMessage<T> msg, String queue, List<String> attributeHeaders)Creates a span based on any tracing metadata in the incoming message.Methods in io.smallrye.reactive.messaging.rabbitmq.tracing with parameters of type Message Modifier and Type Method Description static voidTracingUtils. createOutgoingTrace(Message<?> message, Map<String,Object> headers, String exchange, String routingKey, List<String> attributeHeaders)Creates a new outgoing message span message, and ensures span metadata is added to the message headers. -
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()
-