Modifier and Type | Method and Description |
---|---|
CompletionStage<Void> |
KafkaPriceMessageConsumer.consume(Message<Double> price) |
Modifier and Type | Method and Description |
---|---|
<M extends Message<? extends T>> |
MutinyEmitter.send(M msg)
Sends a message to the channel.
|
Modifier and Type | Method and Description |
---|---|
Message<?> |
MessageConverter.convert(Message<?> in,
Type target)
Converts the given message
in into a Message<T> . |
Message<?> |
MessageConverter.IdentityConverter.convert(Message<?> in,
Type target) |
Modifier and Type | Method and 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 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 CompletionStage<Message<?>> |
AbstractMediator.handlePreProcessingAck(Message<?> message) |
protected Function<Message<?>,? extends CompletionStage<? extends Message<?>>> |
AbstractMediator.managePreProcessingAck() |
protected Function<Message<?>,? extends CompletionStage<? extends Message<?>>> |
AbstractMediator.managePreProcessingAck() |
default 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.PublisherBuilder<? extends Message<?>> |
ChannelRegistry.register(String name,
org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder<? extends Message<?>> stream,
boolean broadcast) |
default 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) |
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,
boolean merge) |
Modifier and Type | Method and Description |
---|---|
boolean |
MessageConverter.canConvert(Message<?> in,
Type target)
Checks whether this instance of converter can convert the given message
in into a Message<T> with
T being the type represented by target . |
boolean |
MessageConverter.IdentityConverter.canConvert(Message<?> in,
Type target) |
Message<?> |
MessageConverter.convert(Message<?> in,
Type target)
Converts the given message
in into a Message<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) |
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.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 publisher
|
default 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.PublisherBuilder<? extends Message<?>> |
ChannelRegistry.register(String name,
org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder<? extends Message<?>> stream,
boolean broadcast) |
default 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) |
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,
boolean merge) |
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 | Method and Description |
---|---|
void |
AmqpCreditBasedSender.onNext(Message<?> message) |
Modifier and Type | Method and Description |
---|---|
void |
AmqpCreditBasedSender.subscribe(org.reactivestreams.Subscriber<? super Message<?>> subscriber) |
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 | 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 | Field and Description |
---|---|
protected AtomicReference<io.smallrye.mutiny.subscription.MultiEmitter<? super Message<? extends T>>> |
AbstractEmitter.internal |
protected io.smallrye.mutiny.Multi<Message<? extends T>> |
AbstractEmitter.publisher |
Modifier and Type | Method and Description |
---|---|
<M extends Message<? extends T>> |
MutinyEmitterImpl.send(M msg) |
<M extends Message<? extends T>> |
EmitterImpl.send(M msg) |
Modifier and Type | Method and Description |
---|---|
org.reactivestreams.Publisher<Message<? extends T>> |
AbstractEmitter.getPublisher() |
Modifier and Type | Method and Description |
---|---|
protected void |
AbstractEmitter.emit(Message<? extends T> message) |
Modifier and Type | Method and Description |
---|---|
static org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder<? extends Message<?>> |
BroadcastHelper.broadcastPublisher(org.reactivestreams.Publisher<? extends Message<?>> publisher,
int numberOfSubscriberBeforeConnecting)
Wraps an existing
Publisher for broadcasting. |
Modifier and Type | Method and Description |
---|---|
static org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder<? extends Message<?>> |
BroadcastHelper.broadcastPublisher(org.reactivestreams.Publisher<? extends Message<?>> publisher,
int numberOfSubscriberBeforeConnecting)
Wraps an existing
Publisher for broadcasting. |
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,
boolean broadcast) |
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,
boolean merge) |
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,
boolean broadcast) |
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,
boolean merge) |
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) |
static <K,T> OutgoingKafkaRecord<K,T> |
KafkaRecord.from(Message<T> message) |
Modifier and Type | Method and Description |
---|---|
static <T,K> Message<T> |
KafkaMetadataUtil.writeOutgoingKafkaMetadata(Message<T> msg,
OutgoingKafkaRecordMetadata<K> outgoingKafkaRecordMetadata)
Write
OutgoingKafkaRecordMetadata to a Message . |
Modifier and Type | Method and Description |
---|---|
static Optional<IncomingKafkaRecordMetadata> |
KafkaMetadataUtil.readIncomingKafkaMetadata(Message<?> msg)
Read
IncomingKafkaRecordMetadata from a Message . |
static <T,K> Message<T> |
KafkaMetadataUtil.writeOutgoingKafkaMetadata(Message<T> msg,
OutgoingKafkaRecordMetadata<K> outgoingKafkaRecordMetadata)
Write
OutgoingKafkaRecordMetadata to a Message . |
Modifier and Type | Method and Description |
---|---|
Message<?> |
ConsumerRecordConverter.convert(Message<?> in,
Type target) |
Message<?> |
RecordConverter.convert(Message<?> in,
Type target) |
Modifier and Type | Method and Description |
---|---|
boolean |
ConsumerRecordConverter.canConvert(Message<?> in,
Type target) |
boolean |
RecordConverter.canConvert(Message<?> in,
Type target) |
Message<?> |
ConsumerRecordConverter.convert(Message<?> in,
Type target) |
Message<?> |
RecordConverter.convert(Message<?> in,
Type target) |
Modifier and Type | Method and Description |
---|---|
void |
KafkaLogging.nackingMessage(Message message,
String topic,
Throwable t) |
void |
KafkaLogging_$logger.nackingMessage(Message message,
String topic,
Throwable t) |
void |
KafkaLogging.sendingMessageToTopic(Message message,
String topic) |
void |
KafkaLogging_$logger.sendingMessageToTopic(Message message,
String topic) |
void |
KafkaLogging.successfullyToTopic(Message message,
String topic) |
void |
KafkaLogging_$logger.successfullyToTopic(Message message,
String topic) |
Modifier and Type | Method and Description |
---|---|
org.eclipse.microprofile.reactive.streams.operators.SubscriberBuilder<? extends Message<?>,Void> |
KafkaSink.getSink() |
Modifier and Type | Method and 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) |
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 |
IncomingRabbitMQMessage<T>
An implementation of
Message suitable for incoming RabbitMQ messages. |
Modifier and Type | Method and 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.
|
Modifier and Type | Method and Description |
---|---|
static RabbitMQMessageConverter.OutgoingRabbitMQMessage |
RabbitMQMessageConverter.convert(Message<?> message,
String exchange,
String defaultRoutingKey,
Optional<Long> defaultTtl,
boolean isTracingEnabled,
List<String> attributeHeaders)
Converts the supplied
Message to an RabbitMQMessageConverter.OutgoingRabbitMQMessage . |
void |
RabbitMQMessageSender.onNext(Message<?> message)
Data notification sent by the
Publisher in response to requests to Subscription.request(long) . |
Modifier and Type | Method and Description |
---|---|
void |
RabbitMQMessageSender.subscribe(org.reactivestreams.Subscriber<? super Message<?>> subscriber)
Request
Publisher to start streaming data. |
Modifier and Type | Method and 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.
|
Modifier and Type | Method and Description |
---|---|
static void |
TracingUtils.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.
|
Modifier and Type | Method and Description |
---|---|
<M extends Message<? extends T>> |
Emitter.send(M msg)
Sends a message 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,
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,
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.
|
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.
|
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 Message<T> |
Message.withNack(Function<Throwable,CompletionStage<Void>> nack)
Creates a new instance of
Message with the given negative-acknowledgement function. |
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.
|
Modifier and Type | Method and Description |
---|---|
io.smallrye.mutiny.Multi<Message<Double>> |
KafkaPriceMessageProducer.generate() |
Copyright © 2018–2021 SmallRye. All rights reserved.