Skip navigation links
Reactor RabbitMQ
A B C D E G H I L M N O P Q R S T U W 

A

abort() - Method in class reactor.rabbitmq.ChannelProxy
 
abort(int, String) - Method in class reactor.rabbitmq.ChannelProxy
 
abort() - Method in class reactor.rabbitmq.IdempotentClosedConnection
 
abort(int, String) - Method in class reactor.rabbitmq.IdempotentClosedConnection
 
abort(int) - Method in class reactor.rabbitmq.IdempotentClosedConnection
 
abort(int, String, int) - Method in class reactor.rabbitmq.IdempotentClosedConnection
 
accept(SignalType, Channel) - Method in class reactor.rabbitmq.ChannelCloseHandlers.SenderChannelCloseHandler
 
accept(Receiver.AcknowledgmentContext, Exception) - Method in class reactor.rabbitmq.ExceptionHandlers.RetryAcknowledgmentExceptionHandler
 
accept(Sender.SendContext, Exception) - Method in class reactor.rabbitmq.ExceptionHandlers.RetrySendingExceptionHandler
 
ack(boolean) - Method in class reactor.rabbitmq.AcknowledgableDelivery
Acknowledges this message if it has not been previously acked or nacked.
ack() - Method in class reactor.rabbitmq.AcknowledgableDelivery
Acknowledges this message if it has not been previously acked or nacked.
AcknowledgableDelivery - Class in reactor.rabbitmq
A RabbitMQ Delivery that can be manually acknowledged or rejected.
AcknowledgableDelivery(Delivery, Channel, BiConsumer<Receiver.AcknowledgmentContext, Exception>) - Constructor for class reactor.rabbitmq.AcknowledgableDelivery
Made public only for testing purposes.
AcknowledgmentContext(AcknowledgableDelivery, Consumer<AcknowledgableDelivery>) - Constructor for class reactor.rabbitmq.Receiver.AcknowledgmentContext
 
ackOrNack() - Method in class reactor.rabbitmq.Receiver.AcknowledgmentContext
 
addBlockedListener(BlockedListener) - Method in class reactor.rabbitmq.IdempotentClosedConnection
 
addBlockedListener(BlockedCallback, UnblockedCallback) - Method in class reactor.rabbitmq.IdempotentClosedConnection
 
addConfirmListener(ConfirmListener) - Method in class reactor.rabbitmq.ChannelProxy
 
addConfirmListener(ConfirmCallback, ConfirmCallback) - Method in class reactor.rabbitmq.ChannelProxy
 
addReturnListener(ReturnListener) - Method in class reactor.rabbitmq.ChannelProxy
 
addReturnListener(ReturnCallback) - Method in class reactor.rabbitmq.ChannelProxy
 
addShutdownListener(ShutdownListener) - Method in class reactor.rabbitmq.ChannelProxy
 
addShutdownListener(ShutdownListener) - Method in class reactor.rabbitmq.IdempotentClosedConnection
 
apply(T) - Method in interface reactor.rabbitmq.Utils.ExceptionFunction
 
apply(ConnectionFactory) - Method in class reactor.rabbitmq.Utils.SingleConnectionSupplier
 
arguments(Map<String, Object>) - Method in class reactor.rabbitmq.BindingSpecification
Arguments of the binding.
arguments(Map<String, Object>) - Method in class reactor.rabbitmq.ConsumeOptions
 
arguments(Map<String, Object>) - Method in class reactor.rabbitmq.ExchangeSpecification
 
arguments - Variable in class reactor.rabbitmq.QueueSpecification
 
arguments(Map<String, Object>) - Method in class reactor.rabbitmq.QueueSpecification
 
asyncCompletableRpc(Method) - Method in class reactor.rabbitmq.ChannelProxy
 
asyncRpc(Method) - Method in class reactor.rabbitmq.ChannelProxy
 
autoDelete(boolean) - Method in class reactor.rabbitmq.ExchangeSpecification
 
autoDelete - Variable in class reactor.rabbitmq.QueueSpecification
 
autoDelete(boolean) - Method in class reactor.rabbitmq.QueueSpecification
 

B

basicAck(long, boolean) - Method in class reactor.rabbitmq.ChannelProxy
 
basicCancel(String) - Method in class reactor.rabbitmq.ChannelProxy
 
basicConsume(String, Consumer) - Method in class reactor.rabbitmq.ChannelProxy
 
basicConsume(String, DeliverCallback, CancelCallback) - Method in class reactor.rabbitmq.ChannelProxy
 
basicConsume(String, DeliverCallback, ConsumerShutdownSignalCallback) - Method in class reactor.rabbitmq.ChannelProxy
 
basicConsume(String, DeliverCallback, CancelCallback, ConsumerShutdownSignalCallback) - Method in class reactor.rabbitmq.ChannelProxy
 
basicConsume(String, boolean, Consumer) - Method in class reactor.rabbitmq.ChannelProxy
 
basicConsume(String, boolean, DeliverCallback, CancelCallback) - Method in class reactor.rabbitmq.ChannelProxy
 
basicConsume(String, boolean, DeliverCallback, ConsumerShutdownSignalCallback) - Method in class reactor.rabbitmq.ChannelProxy
 
basicConsume(String, boolean, DeliverCallback, CancelCallback, ConsumerShutdownSignalCallback) - Method in class reactor.rabbitmq.ChannelProxy
 
basicConsume(String, boolean, Map<String, Object>, Consumer) - Method in class reactor.rabbitmq.ChannelProxy
 
basicConsume(String, boolean, Map<String, Object>, DeliverCallback, CancelCallback) - Method in class reactor.rabbitmq.ChannelProxy
 
basicConsume(String, boolean, Map<String, Object>, DeliverCallback, ConsumerShutdownSignalCallback) - Method in class reactor.rabbitmq.ChannelProxy
 
basicConsume(String, boolean, Map<String, Object>, DeliverCallback, CancelCallback, ConsumerShutdownSignalCallback) - Method in class reactor.rabbitmq.ChannelProxy
 
basicConsume(String, boolean, String, Consumer) - Method in class reactor.rabbitmq.ChannelProxy
 
basicConsume(String, boolean, String, DeliverCallback, CancelCallback) - Method in class reactor.rabbitmq.ChannelProxy
 
basicConsume(String, boolean, String, DeliverCallback, ConsumerShutdownSignalCallback) - Method in class reactor.rabbitmq.ChannelProxy
 
basicConsume(String, boolean, String, DeliverCallback, CancelCallback, ConsumerShutdownSignalCallback) - Method in class reactor.rabbitmq.ChannelProxy
 
basicConsume(String, boolean, String, boolean, boolean, Map<String, Object>, Consumer) - Method in class reactor.rabbitmq.ChannelProxy
 
basicConsume(String, boolean, String, boolean, boolean, Map<String, Object>, DeliverCallback, CancelCallback) - Method in class reactor.rabbitmq.ChannelProxy
 
basicConsume(String, boolean, String, boolean, boolean, Map<String, Object>, DeliverCallback, ConsumerShutdownSignalCallback) - Method in class reactor.rabbitmq.ChannelProxy
 
basicConsume(String, boolean, String, boolean, boolean, Map<String, Object>, DeliverCallback, CancelCallback, ConsumerShutdownSignalCallback) - Method in class reactor.rabbitmq.ChannelProxy
 
basicGet(String, boolean) - Method in class reactor.rabbitmq.ChannelProxy
 
basicNack(long, boolean, boolean) - Method in class reactor.rabbitmq.ChannelProxy
 
basicPublish(String, String, AMQP.BasicProperties, byte[]) - Method in class reactor.rabbitmq.ChannelProxy
 
basicPublish(String, String, boolean, AMQP.BasicProperties, byte[]) - Method in class reactor.rabbitmq.ChannelProxy
 
basicPublish(String, String, boolean, boolean, AMQP.BasicProperties, byte[]) - Method in class reactor.rabbitmq.ChannelProxy
 
basicQos(int, int, boolean) - Method in class reactor.rabbitmq.ChannelProxy
 
basicQos(int, boolean) - Method in class reactor.rabbitmq.ChannelProxy
 
basicQos(int) - Method in class reactor.rabbitmq.ChannelProxy
 
basicRecover() - Method in class reactor.rabbitmq.ChannelProxy
 
basicRecover(boolean) - Method in class reactor.rabbitmq.ChannelProxy
 
basicReject(long, boolean) - Method in class reactor.rabbitmq.ChannelProxy
 
bind(BindingSpecification) - Method in class reactor.rabbitmq.Sender
Bind a queue to an exchange.
bind(BindingSpecification, ResourceManagementOptions) - Method in class reactor.rabbitmq.Sender
Bind a queue to an exchange.
bindExchange(BindingSpecification) - Method in class reactor.rabbitmq.Sender
Bind an exchange to another exchange.
bindExchange(BindingSpecification, ResourceManagementOptions) - Method in class reactor.rabbitmq.Sender
Bind an exchange to another exchange.
binding() - Static method in class reactor.rabbitmq.BindingSpecification
 
binding(String, String, String) - Static method in class reactor.rabbitmq.BindingSpecification
Create an exchange-to-queue binding specification.
binding(String, String, String) - Static method in class reactor.rabbitmq.ResourcesSpecification
 
BindingSpecification - Class in reactor.rabbitmq
Fluent API to specify the binding between AMQP resources.
BindingSpecification() - Constructor for class reactor.rabbitmq.BindingSpecification
 
bindQueue(BindingSpecification) - Method in class reactor.rabbitmq.Sender
Bind a queue to an exchange.
bindQueue(BindingSpecification, ResourceManagementOptions) - Method in class reactor.rabbitmq.Sender
Bind a queue to an exchange.

C

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
Factory to create default ChannelPool instances.
ChannelPoolFactory() - Constructor for class reactor.rabbitmq.ChannelPoolFactory
 
ChannelPoolOptions - Class in reactor.rabbitmq
Options to when creating a ChannelPool.
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
A Function to customize the connection Mono used in the created Receiver instance.
connectionMonoConfigurator(Function<Mono<? extends Connection>, Mono<? extends Connection>>) - Method in class reactor.rabbitmq.SenderOptions
A Function to customize the connection Mono used in the created Sender instance.
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
Options for Receiver#consume* methods.
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
 

D

declare(QueueSpecification) - Method in class reactor.rabbitmq.Sender
Declare a queue following the specification.
declare(QueueSpecification, ResourceManagementOptions) - Method in class reactor.rabbitmq.Sender
Declare a queue following the specification and the resource management options.
declare(ExchangeSpecification) - Method in class reactor.rabbitmq.Sender
Declare an exchange.
declare(ExchangeSpecification, ResourceManagementOptions) - Method in class reactor.rabbitmq.Sender
Declare an exchange.
declareExchange(ExchangeSpecification) - Method in class reactor.rabbitmq.Sender
Declare an exchange.
declareExchange(ExchangeSpecification, ResourceManagementOptions) - Method in class reactor.rabbitmq.Sender
Declare an exchange.
declareQueue(QueueSpecification) - Method in class reactor.rabbitmq.Sender
Declare a queue following the specification.
declareQueue(QueueSpecification, ResourceManagementOptions) - Method in class reactor.rabbitmq.Sender
Declare a queue following the specification and the resource management options.
delete(QueueSpecification) - Method in class reactor.rabbitmq.Sender
Delete a queue.
delete(QueueSpecification, ResourceManagementOptions) - Method in class reactor.rabbitmq.Sender
Delete a queue.
delete(QueueSpecification, boolean, boolean) - Method in class reactor.rabbitmq.Sender
Delete a queue.
delete(QueueSpecification, boolean, boolean, ResourceManagementOptions) - Method in class reactor.rabbitmq.Sender
Delete a queue.
delete(ExchangeSpecification) - Method in class reactor.rabbitmq.Sender
Delete an exchange.
delete(ExchangeSpecification, ResourceManagementOptions) - Method in class reactor.rabbitmq.Sender
Delete an exchange.
delete(ExchangeSpecification, boolean) - Method in class reactor.rabbitmq.Sender
Delete an exchange.
delete(ExchangeSpecification, boolean, ResourceManagementOptions) - Method in class reactor.rabbitmq.Sender
Delete an exchange.
deleteExchange(ExchangeSpecification, boolean) - Method in class reactor.rabbitmq.Sender
Delete an exchange.
deleteExchange(ExchangeSpecification, boolean, ResourceManagementOptions) - Method in class reactor.rabbitmq.Sender
Delete an exchange.
deleteQueue(QueueSpecification, boolean, boolean) - Method in class reactor.rabbitmq.Sender
Delete a queue.
deleteQueue(QueueSpecification, boolean, boolean, ResourceManagementOptions) - Method in class reactor.rabbitmq.Sender
Delete a queue.
durable(boolean) - Method in class reactor.rabbitmq.ExchangeSpecification
 
durable - Variable in class reactor.rabbitmq.QueueSpecification
 
durable(boolean) - Method in class reactor.rabbitmq.QueueSpecification
 

E

exceptionHandler(BiConsumer<Receiver.AcknowledgmentContext, Exception>) - Method in class reactor.rabbitmq.ConsumeOptions
 
exceptionHandler(BiConsumer<Sender.SendContext, Exception>) - Method in class reactor.rabbitmq.SendOptions
 
ExceptionHandlers - Class in reactor.rabbitmq
 
ExceptionHandlers() - Constructor for class reactor.rabbitmq.ExceptionHandlers
 
ExceptionHandlers.ConnectionRecoveryTriggeringPredicate - Class in reactor.rabbitmq
 
ExceptionHandlers.ExceptionPredicate - Class in reactor.rabbitmq
 
ExceptionHandlers.RetryAcknowledgmentExceptionHandler - Class in reactor.rabbitmq
 
ExceptionHandlers.RetrySendingExceptionHandler - Class in reactor.rabbitmq
 
ExceptionHandlers.SimpleRetryTemplate - Class in reactor.rabbitmq
 
ExceptionPredicate(Map<Class<? extends Throwable>, Boolean>) - Constructor for class reactor.rabbitmq.ExceptionHandlers.ExceptionPredicate
 
exchange(String) - Method in class reactor.rabbitmq.BindingSpecification
The exchange to bind from.
exchange() - Static method in class reactor.rabbitmq.ExchangeSpecification
 
exchange(String) - Static method in class reactor.rabbitmq.ExchangeSpecification
 
exchange(String) - Static method in class reactor.rabbitmq.ResourcesSpecification
 
exchangeBind(String, String, String) - Method in class reactor.rabbitmq.ChannelProxy
 
exchangeBind(String, String, String, Map<String, Object>) - Method in class reactor.rabbitmq.ChannelProxy
 
exchangeBinding(String, String, String) - Static method in class reactor.rabbitmq.BindingSpecification
Creates an exchange-to-exchange binding specification.
exchangeBindNoWait(String, String, String, Map<String, Object>) - Method in class reactor.rabbitmq.ChannelProxy
 
exchangeDeclare(String, String) - Method in class reactor.rabbitmq.ChannelProxy
 
exchangeDeclare(String, BuiltinExchangeType) - Method in class reactor.rabbitmq.ChannelProxy
 
exchangeDeclare(String, String, boolean) - Method in class reactor.rabbitmq.ChannelProxy
 
exchangeDeclare(String, BuiltinExchangeType, boolean) - Method in class reactor.rabbitmq.ChannelProxy
 
exchangeDeclare(String, String, boolean, boolean, Map<String, Object>) - Method in class reactor.rabbitmq.ChannelProxy
 
exchangeDeclare(String, BuiltinExchangeType, boolean, boolean, Map<String, Object>) - Method in class reactor.rabbitmq.ChannelProxy
 
exchangeDeclare(String, String, boolean, boolean, boolean, Map<String, Object>) - Method in class reactor.rabbitmq.ChannelProxy
 
exchangeDeclare(String, BuiltinExchangeType, boolean, boolean, boolean, Map<String, Object>) - Method in class reactor.rabbitmq.ChannelProxy
 
exchangeDeclareNoWait(String, String, boolean, boolean, boolean, Map<String, Object>) - Method in class reactor.rabbitmq.ChannelProxy
 
exchangeDeclareNoWait(String, BuiltinExchangeType, boolean, boolean, boolean, Map<String, Object>) - Method in class reactor.rabbitmq.ChannelProxy
 
exchangeDeclarePassive(String) - Method in class reactor.rabbitmq.ChannelProxy
 
exchangeDelete(String, boolean) - Method in class reactor.rabbitmq.ChannelProxy
 
exchangeDelete(String) - Method in class reactor.rabbitmq.ChannelProxy
 
exchangeDeleteNoWait(String, boolean) - Method in class reactor.rabbitmq.ChannelProxy
 
exchangeFrom(String) - Method in class reactor.rabbitmq.BindingSpecification
The exchange to bind from.
ExchangeSpecification - Class in reactor.rabbitmq
Fluent API to specify creation of an exchange.
ExchangeSpecification() - Constructor for class reactor.rabbitmq.ExchangeSpecification
 
exchangeTo(String) - Method in class reactor.rabbitmq.BindingSpecification
The exchange to bind to.
exchangeUnbind(String, String, String) - Method in class reactor.rabbitmq.ChannelProxy
 
exchangeUnbind(String, String, String, Map<String, Object>) - Method in class reactor.rabbitmq.ChannelProxy
 
exchangeUnbindNoWait(String, String, String, Map<String, Object>) - Method in class reactor.rabbitmq.ChannelProxy
 
exclusive - Variable in class reactor.rabbitmq.QueueSpecification
 
exclusive(boolean) - Method in class reactor.rabbitmq.QueueSpecification
 

G

getAddress() - Method in class reactor.rabbitmq.IdempotentClosedConnection
 
getArguments() - Method in class reactor.rabbitmq.BindingSpecification
 
getArguments() - Method in class reactor.rabbitmq.ConsumeOptions
 
getArguments() - Method in class reactor.rabbitmq.ExchangeSpecification
 
getArguments() - Method in class reactor.rabbitmq.QueueSpecification
 
getBody() - Method in class reactor.rabbitmq.OutboundMessage
Defines the main body of the message in byte array form.
getChannel() - Method in class reactor.rabbitmq.Sender.SendContext
 
getChannelCallback() - Method in class reactor.rabbitmq.ConsumeOptions
 
getChannelCloseHandler() - Method in interface reactor.rabbitmq.ChannelPool
The closing logic when the Channel is disposed.
getChannelCloseHandler() - Method in class reactor.rabbitmq.SenderOptions
Returns the channel closing logic.
getChannelCloseHandler() - Method in class reactor.rabbitmq.SendOptions
Return the channel closing logic.
getChannelMax() - Method in class reactor.rabbitmq.IdempotentClosedConnection
 
getChannelMono() - Method in interface reactor.rabbitmq.ChannelPool
The Channel to use for sending a flux of messages.
getChannelMono() - Method in class reactor.rabbitmq.ResourceManagementOptions
 
getChannelMono() - Method in class reactor.rabbitmq.SenderOptions
Returns the channel mono to use in send methods.
getChannelMono() - Method in class reactor.rabbitmq.SendOptions
Return the channel mono to use to send messages.
getChannelNumber() - Method in class reactor.rabbitmq.ChannelProxy
 
getClientProperties() - Method in class reactor.rabbitmq.IdempotentClosedConnection
 
getClientProvidedName() - Method in class reactor.rabbitmq.IdempotentClosedConnection
 
getCloseReason() - Method in class reactor.rabbitmq.ChannelProxy
 
getCloseReason() - Method in class reactor.rabbitmq.IdempotentClosedConnection
 
getConnection() - Method in class reactor.rabbitmq.ChannelProxy
 
getConnectionClosingTimeout() - Method in class reactor.rabbitmq.ReceiverOptions
 
getConnectionClosingTimeout() - Method in class reactor.rabbitmq.SenderOptions
 
getConnectionFactory() - Method in class reactor.rabbitmq.ReceiverOptions
 
getConnectionFactory() - Method in class reactor.rabbitmq.SenderOptions
 
getConnectionMono() - Method in class reactor.rabbitmq.ReceiverOptions
 
getConnectionMono() - Method in class reactor.rabbitmq.SenderOptions
 
getConnectionMonoConfigurator() - Method in class reactor.rabbitmq.ReceiverOptions
 
getConnectionMonoConfigurator() - Method in class reactor.rabbitmq.SenderOptions
 
getConnectionSubscriptionScheduler() - Method in class reactor.rabbitmq.ReceiverOptions
 
getConnectionSubscriptionScheduler() - Method in class reactor.rabbitmq.SenderOptions
 
getConnectionSupplier() - Method in class reactor.rabbitmq.ReceiverOptions
 
getConnectionSupplier() - Method in class reactor.rabbitmq.SenderOptions
 
getConsumerTag() - Method in class reactor.rabbitmq.ConsumeOptions
 
getCorrelationMetadata() - Method in class reactor.rabbitmq.CorrelableOutboundMessage
Defines the "correlation" metadata associated with a sent OutboundMessage
getDefaultConsumer() - Method in class reactor.rabbitmq.ChannelProxy
 
getDelegate() - Method in class reactor.rabbitmq.IdempotentClosedConnection
 
getExceptionHandler() - Method in class reactor.rabbitmq.ConsumeOptions
 
getExceptionHandler() - Method in class reactor.rabbitmq.IdempotentClosedConnection
 
getExceptionHandler() - Method in class reactor.rabbitmq.SendOptions
 
getExchange() - Method in class reactor.rabbitmq.BindingSpecification
 
getExchange() - Method in class reactor.rabbitmq.OutboundMessage
Defines the exchange to which the message will be published.
getExchangeTo() - Method in class reactor.rabbitmq.BindingSpecification
 
getFrameMax() - Method in class reactor.rabbitmq.IdempotentClosedConnection
 
getHeartbeat() - Method in class reactor.rabbitmq.IdempotentClosedConnection
 
getHookBeforeEmitBiFunction() - Method in class reactor.rabbitmq.ConsumeOptions
 
getId() - Method in class reactor.rabbitmq.IdempotentClosedConnection
 
getMaxCacheSize() - Method in class reactor.rabbitmq.ChannelPoolOptions
 
getMaxInFlight() - Method in class reactor.rabbitmq.SendOptions
Returns the maximum number of in-flight records that are fetched from the outbound record publisher while publisher confirms are pending.
getMessage() - Method in class reactor.rabbitmq.Sender.SendContext
 
getName() - Method in class reactor.rabbitmq.ExchangeSpecification
 
getName() - Method in class reactor.rabbitmq.QueueSpecification
 
getNextPublishSeqNo() - Method in class reactor.rabbitmq.ChannelProxy
 
getOutboundMessage() - Method in class reactor.rabbitmq.OutboundMessageResult
Defines the message that has been published.
getOverflowStrategy() - Method in class reactor.rabbitmq.ConsumeOptions
 
getPort() - Method in class reactor.rabbitmq.IdempotentClosedConnection
 
getProperties() - Method in class reactor.rabbitmq.OutboundMessage
Defines any additional properties that will be used during the publishing of the message.
getQos() - Method in class reactor.rabbitmq.ConsumeOptions
 
getQueue() - Method in class reactor.rabbitmq.BindingSpecification
 
getResourceManagementChannelMono() - Method in class reactor.rabbitmq.SenderOptions
 
getResourceManagementScheduler() - Method in class reactor.rabbitmq.SenderOptions
 
getRoutingKey() - Method in class reactor.rabbitmq.BindingSpecification
 
getRoutingKey() - Method in class reactor.rabbitmq.OutboundMessage
Defines the routing key to be used if the message has to be routed in a specific way towards a queue
getScheduler() - Method in class reactor.rabbitmq.SendOptions
The scheduler used for publishing send results.
getServerProperties() - Method in class reactor.rabbitmq.IdempotentClosedConnection
 
getStopConsumingBiFunction() - Method in class reactor.rabbitmq.ConsumeOptions
 
getSubscriptionScheduler() - Method in class reactor.rabbitmq.ChannelPoolOptions
 
getType() - Method in class reactor.rabbitmq.ExchangeSpecification
 

H

hookBeforeEmitBiFunction(BiFunction<Long, ? super Delivery, Boolean>) - Method in class reactor.rabbitmq.ConsumeOptions
 

I

IdempotentClosedConnection - Class in reactor.rabbitmq
Implement Connection that ensure closing is idempotent.
IdempotentClosedConnection(Connection) - Constructor for class reactor.rabbitmq.IdempotentClosedConnection
 
internal(boolean) - Method in class reactor.rabbitmq.ExchangeSpecification
 
isAck() - Method in class reactor.rabbitmq.OutboundMessageResult
Defines whether the message has been acknowledged by the broker or not.
isAutoDelete() - Method in class reactor.rabbitmq.ExchangeSpecification
 
isAutoDelete() - Method in class reactor.rabbitmq.QueueSpecification
 
isDurable() - Method in class reactor.rabbitmq.ExchangeSpecification
 
isDurable() - Method in class reactor.rabbitmq.QueueSpecification
 
isExclusive() - Method in class reactor.rabbitmq.QueueSpecification
 
isInternal() - Method in class reactor.rabbitmq.ExchangeSpecification
 
isOpen() - Method in class reactor.rabbitmq.ChannelProxy
 
isOpen() - Method in class reactor.rabbitmq.IdempotentClosedConnection
 
isPassive() - Method in class reactor.rabbitmq.ExchangeSpecification
 
isPassive() - Method in class reactor.rabbitmq.QueueSpecification
 
isRecoverable(Connection) - Method in class reactor.rabbitmq.Receiver
 
isRecoverable(Channel) - Method in class reactor.rabbitmq.Receiver
 
isReturned() - Method in class reactor.rabbitmq.OutboundMessageResult
Defines whether the message has been returned by the broker or not.
isTrackReturned() - Method in class reactor.rabbitmq.SendOptions
Returns whether we should track returned (undeliverable) messages when publisher confirms are in use.

L

lockChannel() - Method in class reactor.rabbitmq.RpcClient
 

M

maxCacheSize(int) - Method in class reactor.rabbitmq.ChannelPoolOptions
Set the maximum size of the pool.
maxInFlight(int) - Method in class reactor.rabbitmq.SendOptions
Set the maximum number of in-flight records that are fetched from the outbound record publisher while publisher confirms are pending.
maxInFlight(int, Scheduler) - Method in class reactor.rabbitmq.SendOptions
Set the maximum number of in-flight records that are fetched from the outbound record publisher while publisher confirms are pending.
message - Variable in class reactor.rabbitmq.Sender.SendContext
 
messageCount(String) - Method in class reactor.rabbitmq.ChannelProxy
 

N

nack(boolean, boolean) - Method in class reactor.rabbitmq.AcknowledgableDelivery
Rejects this message if it has not been previously acked or nacked.
nack(boolean) - Method in class reactor.rabbitmq.AcknowledgableDelivery
Rejects this message if it has not been previously acked or nacked.
name(String) - Method in class reactor.rabbitmq.ExchangeSpecification
 
name - Variable in class reactor.rabbitmq.QueueSpecification
 
name(String) - Method in class reactor.rabbitmq.QueueSpecification
 
notifyListeners() - Method in class reactor.rabbitmq.ChannelProxy
 
notifyListeners() - Method in class reactor.rabbitmq.IdempotentClosedConnection
 

O

OutboundMessage - Class in reactor.rabbitmq
Outbound message meant to be sent by a Sender.
OutboundMessage(String, String, byte[]) - Constructor for class reactor.rabbitmq.OutboundMessage
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.
OutboundMessage(String, String, AMQP.BasicProperties, byte[]) - Constructor for class reactor.rabbitmq.OutboundMessage
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.
OutboundMessageResult<OMSG extends OutboundMessage> - Class in reactor.rabbitmq
Result of a sent message when using publisher confirm.
OutboundMessageResult(OMSG, boolean) - Constructor for class reactor.rabbitmq.OutboundMessageResult
Constructs a result which is described by the initial message that has been published and the acknowledgment status.
OutboundMessageResult(OMSG, boolean, boolean) - Constructor for class reactor.rabbitmq.OutboundMessageResult
Constructs a result which is described by the initial message that has been published, the acknowledgment status, and the returned status.
overflowStrategy(FluxSink.OverflowStrategy) - Method in class reactor.rabbitmq.ConsumeOptions
 

P

passive(boolean) - Method in class reactor.rabbitmq.ExchangeSpecification
 
passive - Variable in class reactor.rabbitmq.QueueSpecification
 
passive(boolean) - Method in class reactor.rabbitmq.QueueSpecification
 
publish(OutboundMessage) - Method in class reactor.rabbitmq.Sender.ConfirmSendContext
 
publish() - Method in class reactor.rabbitmq.Sender.ConfirmSendContext
 
publish(OutboundMessage) - Method in class reactor.rabbitmq.Sender.SendContext
 
publish() - Method in class reactor.rabbitmq.Sender.SendContext
 

Q

qos(int) - Method in class reactor.rabbitmq.ConsumeOptions
 
queue(String) - Method in class reactor.rabbitmq.BindingSpecification
The queue to bind to.
queue() - Static method in class reactor.rabbitmq.QueueSpecification
 
queue(String) - Static method in class reactor.rabbitmq.QueueSpecification
 
queue(String) - Static method in class reactor.rabbitmq.ResourcesSpecification
 
queueBind(String, String, String) - Method in class reactor.rabbitmq.ChannelProxy
 
queueBind(String, String, String, Map<String, Object>) - Method in class reactor.rabbitmq.ChannelProxy
 
queueBinding(String, String, String) - Static method in class reactor.rabbitmq.BindingSpecification
Create an exchange-to-queue binding specification.
queueBindNoWait(String, String, String, Map<String, Object>) - Method in class reactor.rabbitmq.ChannelProxy
 
queueDeclare() - Method in class reactor.rabbitmq.ChannelProxy
 
queueDeclare(String, boolean, boolean, boolean, Map<String, Object>) - Method in class reactor.rabbitmq.ChannelProxy
 
queueDeclareNoWait(String, boolean, boolean, boolean, Map<String, Object>) - Method in class reactor.rabbitmq.ChannelProxy
 
queueDeclarePassive(String) - Method in class reactor.rabbitmq.ChannelProxy
 
queueDelete(String) - Method in class reactor.rabbitmq.ChannelProxy
 
queueDelete(String, boolean, boolean) - Method in class reactor.rabbitmq.ChannelProxy
 
queueDeleteNoWait(String, boolean, boolean) - Method in class reactor.rabbitmq.ChannelProxy
 
queuePurge(String) - Method in class reactor.rabbitmq.ChannelProxy
 
QueueSpecification - Class in reactor.rabbitmq
Fluent API to specify the creation of a queue.
QueueSpecification() - Constructor for class reactor.rabbitmq.QueueSpecification
 
queueUnbind(String, String, String) - Method in class reactor.rabbitmq.ChannelProxy
 
queueUnbind(String, String, String, Map<String, Object>) - Method in class reactor.rabbitmq.ChannelProxy
 

R

RabbitFlux - Class in reactor.rabbitmq
Factory for Sender and Receiver.
RabbitFlux() - Constructor for class reactor.rabbitmq.RabbitFlux
 
RabbitFluxException - Exception in reactor.rabbitmq
Common exception class for Reactor RabbitMQ library.
RabbitFluxException() - Constructor for exception reactor.rabbitmq.RabbitFluxException
 
RabbitFluxException(String) - Constructor for exception reactor.rabbitmq.RabbitFluxException
 
RabbitFluxException(String, Throwable) - Constructor for exception reactor.rabbitmq.RabbitFluxException
 
RabbitFluxException(Throwable) - Constructor for exception reactor.rabbitmq.RabbitFluxException
 
RabbitFluxException(String, Throwable, boolean, boolean) - Constructor for exception reactor.rabbitmq.RabbitFluxException
 
RabbitFluxRetryTimeoutException - Exception in reactor.rabbitmq
 
RabbitFluxRetryTimeoutException(String, Throwable) - Constructor for exception reactor.rabbitmq.RabbitFluxRetryTimeoutException
 
reactor.rabbitmq - package reactor.rabbitmq
Core package of the Reactor RabbitMQ integration.
Receiver - Class in reactor.rabbitmq
Reactive abstraction to consume messages as a Flux.
Receiver() - Constructor for class reactor.rabbitmq.Receiver
 
Receiver(ReceiverOptions) - Constructor for class reactor.rabbitmq.Receiver
 
Receiver.AcknowledgmentContext - Class in reactor.rabbitmq
 
ReceiverOptions - Class in reactor.rabbitmq
Options for Receiver creation.
ReceiverOptions() - Constructor for class reactor.rabbitmq.ReceiverOptions
 
removeBlockedListener(BlockedListener) - Method in class reactor.rabbitmq.IdempotentClosedConnection
 
removeConfirmListener(ConfirmListener) - Method in class reactor.rabbitmq.ChannelProxy
 
removeReturnListener(ReturnListener) - Method in class reactor.rabbitmq.ChannelProxy
 
removeShutdownListener(ShutdownListener) - Method in class reactor.rabbitmq.ChannelProxy
 
removeShutdownListener(ShutdownListener) - Method in class reactor.rabbitmq.IdempotentClosedConnection
 
resourceManagementChannelMono(Mono<? extends Channel>) - Method in class reactor.rabbitmq.SenderOptions
 
ResourceManagementOptions - Class in reactor.rabbitmq
Options for resource management in Sender.
ResourceManagementOptions() - Constructor for class reactor.rabbitmq.ResourceManagementOptions
 
resourceManagementScheduler(Scheduler) - Method in class reactor.rabbitmq.SenderOptions
Resource management scheduler.
ResourcesSpecification - Class in reactor.rabbitmq
ResourcesSpecification() - Constructor for class reactor.rabbitmq.ResourcesSpecification
 
retry(Callable<Void>, Exception) - Method in class reactor.rabbitmq.ExceptionHandlers.SimpleRetryTemplate
 
RetryAcknowledgmentExceptionHandler(Duration, Duration, Predicate<Throwable>) - Constructor for class reactor.rabbitmq.ExceptionHandlers.RetryAcknowledgmentExceptionHandler
 
RetrySendingExceptionHandler(Duration, Duration, Predicate<Throwable>) - Constructor for class reactor.rabbitmq.ExceptionHandlers.RetrySendingExceptionHandler
 
RetrySendingExceptionHandler(Duration, Duration, Predicate<Throwable>, boolean) - Constructor for class reactor.rabbitmq.ExceptionHandlers.RetrySendingExceptionHandler
 
routingKey(String) - Method in class reactor.rabbitmq.BindingSpecification
The routing key for the binding.
rpc(Method) - Method in class reactor.rabbitmq.ChannelProxy
 
rpc(Publisher<RpcClient.RpcRequest>) - Method in class reactor.rabbitmq.RpcClient
 
RpcClient - Class in reactor.rabbitmq
 
RpcClient(Mono<Channel>, String, String, Supplier<String>) - Constructor for class reactor.rabbitmq.RpcClient
 
RpcClient(Mono<Channel>, String, String) - Constructor for class reactor.rabbitmq.RpcClient
 
rpcClient(String, String) - Method in class reactor.rabbitmq.Sender
 
rpcClient(String, String, Supplier<String>) - Method in class reactor.rabbitmq.Sender
 
RpcClient.RpcRequest - Class in reactor.rabbitmq
 
RpcRequest(AMQP.BasicProperties, byte[]) - Constructor for class reactor.rabbitmq.RpcClient.RpcRequest
 
RpcRequest(byte[]) - Constructor for class reactor.rabbitmq.RpcClient.RpcRequest
 

S

send(Publisher<OutboundMessage>) - Method in class reactor.rabbitmq.Sender
 
send(Publisher<OutboundMessage>, SendOptions) - Method in class reactor.rabbitmq.Sender
 
SendContext(Channel, OMSG) - Constructor for class reactor.rabbitmq.Sender.SendContext
 
Sender - Class in reactor.rabbitmq
Reactive abstraction to create resources and send messages.
Sender() - Constructor for class reactor.rabbitmq.Sender
 
Sender(SenderOptions) - Constructor for class reactor.rabbitmq.Sender
 
Sender.ConfirmSendContext<OMSG extends OutboundMessage> - Class in reactor.rabbitmq
 
Sender.SendContext<OMSG extends OutboundMessage> - Class in reactor.rabbitmq
 
SENDER_CHANNEL_CLOSE_HANDLER_INSTANCE - Static variable in class reactor.rabbitmq.ChannelCloseHandlers
 
SenderChannelCloseHandler() - Constructor for class reactor.rabbitmq.ChannelCloseHandlers.SenderChannelCloseHandler
 
SenderOptions - Class in reactor.rabbitmq
Options for Sender creation.
SenderOptions() - Constructor for class reactor.rabbitmq.SenderOptions
 
SendOptions - Class in reactor.rabbitmq
Options for Sender#send* methods.
SendOptions() - Constructor for class reactor.rabbitmq.SendOptions
 
sendWithPublishConfirms(Publisher<OutboundMessage>) - Method in class reactor.rabbitmq.Sender
Publish a flux of messages and expect confirmations.
sendWithPublishConfirms(Publisher<OutboundMessage>, SendOptions) - Method in class reactor.rabbitmq.Sender
Publish a flux of messages and expect confirmations.
sendWithTypedPublishConfirms(Publisher<OMSG>) - Method in class reactor.rabbitmq.Sender
Publish a flux of subclass of OutboundMessage and expect confirmations.
sendWithTypedPublishConfirms(Publisher<OMSG>, SendOptions) - Method in class reactor.rabbitmq.Sender
Publish a flux of subclass of OutboundMessage and expect confirmations.
setDefaultConsumer(Consumer) - Method in class reactor.rabbitmq.ChannelProxy
 
setId(String) - Method in class reactor.rabbitmq.IdempotentClosedConnection
 
SimpleRetryTemplate(Duration, Duration, Predicate<Throwable>) - Constructor for class reactor.rabbitmq.ExceptionHandlers.SimpleRetryTemplate
 
SimpleRetryTemplate(Duration, Duration, Predicate<Throwable>, boolean) - Constructor for class reactor.rabbitmq.ExceptionHandlers.SimpleRetryTemplate
 
singleConnectionMono(ConnectionFactory) - Static method in class reactor.rabbitmq.Utils
 
singleConnectionMono(ConnectionFactory, Utils.ExceptionFunction<ConnectionFactory, ? extends Connection>) - Static method in class reactor.rabbitmq.Utils
 
singleConnectionMono(Callable<? extends Connection>) - Static method in class reactor.rabbitmq.Utils
 
singleConnectionSupplier(ConnectionFactory, Utils.ExceptionFunction<ConnectionFactory, ? extends Connection>) - Static method in class reactor.rabbitmq.Utils
 
singleConnectionSupplier(ConnectionFactory) - Static method in class reactor.rabbitmq.Utils
 
singleConnectionSupplier(Callable<? extends Connection>) - Static method in class reactor.rabbitmq.Utils
 
SingleConnectionSupplier(Callable<? extends Connection>) - Constructor for class reactor.rabbitmq.Utils.SingleConnectionSupplier
 
SingleConnectionSupplier(Callable<? extends Connection>, Duration) - Constructor for class reactor.rabbitmq.Utils.SingleConnectionSupplier
 
stopConsumingBiFunction(BiFunction<Long, ? super Delivery, Boolean>) - Method in class reactor.rabbitmq.ConsumeOptions
 
subscriptionScheduler(Scheduler) - Method in class reactor.rabbitmq.ChannelPoolOptions
Set the scheduler to use when opening Channels.

T

test(Throwable) - Method in class reactor.rabbitmq.ExceptionHandlers.ConnectionRecoveryTriggeringPredicate
 
test(Throwable) - Method in class reactor.rabbitmq.ExceptionHandlers.ExceptionPredicate
 
toString() - Method in class reactor.rabbitmq.CorrelableOutboundMessage
 
toString() - Method in class reactor.rabbitmq.OutboundMessage
 
toString() - Method in class reactor.rabbitmq.OutboundMessageResult
 
trackReturned(boolean) - Method in class reactor.rabbitmq.SendOptions
Set whether we should track returned (undeliverable) messages when publisher confirms are in use.
txCommit() - Method in class reactor.rabbitmq.ChannelProxy
 
txRollback() - Method in class reactor.rabbitmq.ChannelProxy
 
txSelect() - Method in class reactor.rabbitmq.ChannelProxy
 
type(String) - Method in class reactor.rabbitmq.ExchangeSpecification
 

U

unbind(BindingSpecification) - Method in class reactor.rabbitmq.Sender
Unbind a queue from an exchange.
unbind(BindingSpecification, ResourceManagementOptions) - Method in class reactor.rabbitmq.Sender
Unbind a queue from an exchange.
unbindExchange(BindingSpecification) - Method in class reactor.rabbitmq.Sender
Unbind an exchange from another exchange.
unbindExchange(BindingSpecification, ResourceManagementOptions) - Method in class reactor.rabbitmq.Sender
Unbind an exchange from another exchange.
unbindQueue(BindingSpecification) - Method in class reactor.rabbitmq.Sender
Unbind a queue from an exchange.
unbindQueue(BindingSpecification, ResourceManagementOptions) - Method in class reactor.rabbitmq.Sender
Unbind a queue from an exchange.
unlockChannel() - Method in class reactor.rabbitmq.RpcClient
 
Utils - Class in reactor.rabbitmq
Set of utilities.
Utils() - Constructor for class reactor.rabbitmq.Utils
 
Utils.ExceptionFunction<T,R> - Interface in reactor.rabbitmq
 
Utils.SingleConnectionSupplier - Class in reactor.rabbitmq
 

W

waitForConfirms() - Method in class reactor.rabbitmq.ChannelProxy
 
waitForConfirms(long) - Method in class reactor.rabbitmq.ChannelProxy
 
waitForConfirmsOrDie() - Method in class reactor.rabbitmq.ChannelProxy
 
waitForConfirmsOrDie(long) - Method in class reactor.rabbitmq.ChannelProxy
 
A B C D E G H I L M N O P Q R S T U W 
Skip navigation links
Reactor RabbitMQ