- cache(Mono<T>) - Method in class reactor.rabbitmq.Receiver
-
- cache(Mono<T>) - Method in class reactor.rabbitmq.Sender
-
- cache(Mono<T>) - Static method in class reactor.rabbitmq.Utils
-
- channel - Variable in class reactor.rabbitmq.Sender.SendContext
-
- channelCallback(Consumer<Channel>) - Method in class reactor.rabbitmq.ConsumeOptions
-
- channelCloseHandler(BiConsumer<SignalType, Channel>) - Method in class reactor.rabbitmq.SenderOptions
-
Set the channel closing logic.
- channelCloseHandler(BiConsumer<SignalType, Channel>) - Method in class reactor.rabbitmq.SendOptions
-
Set the channel closing logic.
- ChannelCloseHandlers - Class in reactor.rabbitmq
-
Helper class to close channels.
- ChannelCloseHandlers() - Constructor for class reactor.rabbitmq.ChannelCloseHandlers
-
- ChannelCloseHandlers.SenderChannelCloseHandler - Class in reactor.rabbitmq
-
Default closing strategy in
Sender
.
- channelMono(Mono<Channel>) - Method in class reactor.rabbitmq.ResourceManagementOptions
-
- channelMono(Mono<? extends Channel>) - Method in class reactor.rabbitmq.SenderOptions
-
Sets the channel mono to use in send methods.
- channelMono(Mono<? extends Channel>) - Method in class reactor.rabbitmq.SendOptions
-
Set the channel mono to use to send messages.
- ChannelPool - Interface in reactor.rabbitmq
-
Contract to obtain a Channel
and close when sending messages.
- channelPool(ChannelPool) - Method in class reactor.rabbitmq.SenderOptions
-
Set the channel pool to use to send messages.
- channelPool(ChannelPool) - Method in class reactor.rabbitmq.SendOptions
-
Set the channel pool to use to send messages.
- ChannelPoolFactory - Class in reactor.rabbitmq
-
- ChannelPoolFactory() - Constructor for class reactor.rabbitmq.ChannelPoolFactory
-
- ChannelPoolOptions - Class in reactor.rabbitmq
-
- ChannelPoolOptions() - Constructor for class reactor.rabbitmq.ChannelPoolOptions
-
- ChannelProxy - Class in reactor.rabbitmq
-
A Channel
proxy that re-open the underlying channel if necessary.
- ChannelProxy(Connection) - Constructor for class reactor.rabbitmq.ChannelProxy
-
- clearBlockedListeners() - Method in class reactor.rabbitmq.IdempotentClosedConnection
-
- clearConfirmListeners() - Method in class reactor.rabbitmq.ChannelProxy
-
- clearReturnListeners() - Method in class reactor.rabbitmq.ChannelProxy
-
- close() - Method in interface reactor.rabbitmq.ChannelPool
-
Close the pool when it is no longer necessary.
- close() - Method in class reactor.rabbitmq.ChannelProxy
-
- close(int, String) - Method in class reactor.rabbitmq.ChannelProxy
-
- close() - Method in class reactor.rabbitmq.IdempotentClosedConnection
-
- close(int, String) - Method in class reactor.rabbitmq.IdempotentClosedConnection
-
- close(int) - Method in class reactor.rabbitmq.IdempotentClosedConnection
-
- close(int, String, int) - Method in class reactor.rabbitmq.IdempotentClosedConnection
-
- close() - Method in class reactor.rabbitmq.Receiver
-
- close() - Method in class reactor.rabbitmq.RpcClient
-
- close() - Method in class reactor.rabbitmq.Sender
-
- completeOnChannelShutdown(Channel, FluxSink<?>) - Method in class reactor.rabbitmq.Receiver
-
- confirmSelect() - Method in class reactor.rabbitmq.ChannelProxy
-
- ConfirmSendContext(Channel, OMSG, Sender.PublishConfirmSubscriber<OMSG>) - Constructor for class reactor.rabbitmq.Sender.ConfirmSendContext
-
- CONNECTION_RECOVERY_PREDICATE - Static variable in class reactor.rabbitmq.ExceptionHandlers
-
- connectionClosingTimeout(Duration) - Method in class reactor.rabbitmq.ReceiverOptions
-
Timeout for closing the
Receiver
connection.
- connectionClosingTimeout(Duration) - Method in class reactor.rabbitmq.SenderOptions
-
Timeout for closing the
Sender
connection.
- connectionFactory(ConnectionFactory) - Method in class reactor.rabbitmq.ReceiverOptions
-
- connectionFactory(ConnectionFactory) - Method in class reactor.rabbitmq.SenderOptions
-
- connectionMono(Mono<? extends Connection>) - Method in class reactor.rabbitmq.ReceiverOptions
-
Set a
Mono
that the created
Receiver
will use for its operations.
- connectionMono(Mono<? extends Connection>) - Method in class reactor.rabbitmq.SenderOptions
-
Set a
Mono
that the created
Sender
will use for its operations.
- connectionMonoConfigurator(Function<Mono<? extends Connection>, Mono<? extends Connection>>) - Method in class reactor.rabbitmq.ReceiverOptions
-
- connectionMonoConfigurator(Function<Mono<? extends Connection>, Mono<? extends Connection>>) - Method in class reactor.rabbitmq.SenderOptions
-
- ConnectionRecoveryTriggeringPredicate() - Constructor for class reactor.rabbitmq.ExceptionHandlers.ConnectionRecoveryTriggeringPredicate
-
- connectionSubscriptionScheduler(Scheduler) - Method in class reactor.rabbitmq.ReceiverOptions
-
Scheduler used on connection creation subscription.
- connectionSubscriptionScheduler(Scheduler) - Method in class reactor.rabbitmq.SenderOptions
-
Scheduler used on connection creation subscription.
- connectionSupplier(Utils.ExceptionFunction<ConnectionFactory, ? extends Connection>) - Method in class reactor.rabbitmq.ReceiverOptions
-
Set a callback that will be passed in the
ConnectionFactory
of this
ReceiverOptions
instance to create a
Connection
.
- connectionSupplier(ConnectionFactory, Utils.ExceptionFunction<ConnectionFactory, ? extends Connection>) - Method in class reactor.rabbitmq.ReceiverOptions
-
Set a callback that will be passed in the given ConnectionFactory
to create a Connection
.
- connectionSupplier(Utils.ExceptionFunction<ConnectionFactory, ? extends Connection>) - Method in class reactor.rabbitmq.SenderOptions
-
Set a callback that will be passed in the
ConnectionFactory
of this
SenderOptions
instance to create a
Connection
.
- connectionSupplier(ConnectionFactory, Utils.ExceptionFunction<ConnectionFactory, ? extends Connection>) - Method in class reactor.rabbitmq.SenderOptions
-
Set a callback that will be passed in the given ConnectionFactory
to create a Connection
.
- consumeAutoAck(String) - Method in class reactor.rabbitmq.Receiver
-
- consumeAutoAck(String, ConsumeOptions) - Method in class reactor.rabbitmq.Receiver
-
- consumeManualAck(String) - Method in class reactor.rabbitmq.Receiver
-
- consumeManualAck(String, ConsumeOptions) - Method in class reactor.rabbitmq.Receiver
-
- consumeNoAck(String) - Method in class reactor.rabbitmq.Receiver
-
- consumeNoAck(String, ConsumeOptions) - Method in class reactor.rabbitmq.Receiver
-
- ConsumeOptions - Class in reactor.rabbitmq
-
- ConsumeOptions() - Constructor for class reactor.rabbitmq.ConsumeOptions
-
- consumerCount(String) - Method in class reactor.rabbitmq.ChannelProxy
-
- consumerTag(String) - Method in class reactor.rabbitmq.ConsumeOptions
-
- CorrelableOutboundMessage<T> - Class in reactor.rabbitmq
-
An outbound message meant to be sent by a
Sender
and may contain (unserialized)
correlated metadata.
- CorrelableOutboundMessage(String, String, byte[], T) - Constructor for class reactor.rabbitmq.CorrelableOutboundMessage
-
Constructs a new message which is described by the body, the target exchange and the routing key which
can be used for smart routing after the message is published to the exchange.
- CorrelableOutboundMessage(String, String, AMQP.BasicProperties, byte[], T) - Constructor for class reactor.rabbitmq.CorrelableOutboundMessage
-
Constructs a new message which is described by the body, the target exchange and the routing key which
can be used for smart routing after the message is published to the exchange.
- createChannel() - Method in class reactor.rabbitmq.IdempotentClosedConnection
-
- createChannel(int) - Method in class reactor.rabbitmq.IdempotentClosedConnection
-
- createChannelPool(Mono<? extends Connection>) - Static method in class reactor.rabbitmq.ChannelPoolFactory
-
- createChannelPool(Mono<? extends Connection>, ChannelPoolOptions) - Static method in class reactor.rabbitmq.ChannelPoolFactory
-
- createReceiver(ReceiverOptions) - Static method in class reactor.rabbitmq.RabbitFlux
-
- createReceiver() - Static method in class reactor.rabbitmq.RabbitFlux
-
- createScheduler(String) - Method in class reactor.rabbitmq.Receiver
-
- createScheduler(String) - Method in class reactor.rabbitmq.Sender
-
- createSender(SenderOptions) - Static method in class reactor.rabbitmq.RabbitFlux
-
- createSender() - Static method in class reactor.rabbitmq.RabbitFlux
-