Package | Description |
---|---|
io.smallrye.reactive.messaging.rabbitmq.ack | |
io.smallrye.reactive.messaging.rabbitmq.fault | |
io.smallrye.reactive.messaging.rabbitmq.tracing |
Modifier and Type | Method and Description |
---|---|
<V> CompletionStage<Void> |
RabbitMQAck.handle(IncomingRabbitMQMessage<V> msg,
io.vertx.mutiny.core.Context context) |
<V> CompletionStage<Void> |
RabbitMQAutoAck.handle(IncomingRabbitMQMessage<V> msg,
io.vertx.mutiny.core.Context context) |
<V> CompletionStage<Void> |
RabbitMQAckHandler.handle(IncomingRabbitMQMessage<V> message,
io.vertx.mutiny.core.Context context)
Handle the request to acknowledge a message.
|
Modifier and Type | Method and Description |
---|---|
<V> CompletionStage<Void> |
RabbitMQFailStop.handle(IncomingRabbitMQMessage<V> msg,
io.vertx.mutiny.core.Context context,
Throwable reason) |
<V> CompletionStage<Void> |
RabbitMQAccept.handle(IncomingRabbitMQMessage<V> msg,
io.vertx.mutiny.core.Context context,
Throwable reason) |
<V> CompletionStage<Void> |
RabbitMQFailureHandler.handle(IncomingRabbitMQMessage<V> message,
io.vertx.mutiny.core.Context context,
Throwable reason)
Handle message failure.
|
<V> CompletionStage<Void> |
RabbitMQReject.handle(IncomingRabbitMQMessage<V> msg,
io.vertx.mutiny.core.Context context,
Throwable reason) |
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.
|
Copyright © 2018–2021 SmallRye. All rights reserved.