Package | Description |
---|---|
com.rabbitmq.client |
The client API proper: classes and interfaces representing the AMQP
connections, channels, and wire-protocol framing descriptors.
|
com.rabbitmq.client.impl |
Implementations of interfaces specified in the client API, and their supporting classes.
|
com.rabbitmq.client.impl.recovery |
Implementation of connection and topology recovery.
|
Modifier and Type | Class and Description |
---|---|
class |
AlreadyClosedException
Thrown when application tries to perform an action on connection/channel
which was already closed
|
Modifier and Type | Method and Description |
---|---|
ShutdownSignalException |
ShutdownNotifier.getCloseReason()
Get the shutdown reason object
|
ShutdownSignalException |
RpcServer.mainloop()
Public API - main server loop.
|
ShutdownSignalException |
ShutdownSignalException.sensibleClone() |
Modifier and Type | Method and Description |
---|---|
void |
ConsumerShutdownSignalCallback.handleShutdownSignal(String consumerTag,
ShutdownSignalException sig)
Called when either the channel or the underlying connection has been shut down.
|
void |
Consumer.handleShutdownSignal(String consumerTag,
ShutdownSignalException sig)
Called when either the channel or the underlying connection has been shut down.
|
void |
DefaultConsumer.handleShutdownSignal(String consumerTag,
ShutdownSignalException sig)
No-op implementation of
Consumer.handleShutdownSignal(java.lang.String, com.rabbitmq.client.ShutdownSignalException) . |
void |
ShutdownListener.shutdownCompleted(ShutdownSignalException cause) |
Modifier and Type | Method and Description |
---|---|
void |
ConnectionFactory.setConnectionRecoveryTriggeringCondition(Predicate<ShutdownSignalException> connectionRecoveryTriggeringCondition)
Allows to decide on automatic connection recovery is triggered.
|
Modifier and Type | Method and Description |
---|---|
RpcClient.Response |
RpcClient.doCall(AMQP.BasicProperties props,
byte[] message,
int timeout) |
Map<String,Object> |
RpcClient.mapCall(Map<String,Object> message)
Perform an AMQP wire-protocol-table based RPC roundtrip
There are some restrictions on the values appearing in the table: they must be of type String , LongString , Integer , BigDecimal , Date ,
or (recursively) a Map of the enclosing type. |
Map<String,Object> |
RpcClient.mapCall(Object[] keyValuePairs)
Perform an AMQP wire-protocol-table based RPC roundtrip, first
constructing the table from an array of alternating keys (in
even-numbered elements, starting at zero) and values (in
odd-numbered elements, starting at one)
Restrictions on value arguments apply as in RpcClient.mapCall(Map) . |
Delivery |
RpcServer.RpcConsumer.nextDelivery() |
byte[] |
RpcClient.primitiveCall(AMQP.BasicProperties props,
byte[] message) |
byte[] |
RpcClient.primitiveCall(AMQP.BasicProperties props,
byte[] message,
int timeout) |
byte[] |
RpcClient.primitiveCall(byte[] message)
Perform a simple byte-array-based RPC roundtrip.
|
RpcClient.Response |
RpcClient.responseCall(byte[] message)
Perform a simple byte-array-based RPC roundtrip
Useful if you need to get at more than just the body of the message
|
RpcClient.Response |
RpcClient.responseCall(byte[] message,
int timeout)
Perform a simple byte-array-based RPC roundtrip
Useful if you need to get at more than just the body of the message
|
String |
RpcClient.stringCall(String message)
Perform a simple string-based RPC roundtrip.
|
Constructor and Description |
---|
AlreadyClosedException(ShutdownSignalException sse) |
AlreadyClosedException(ShutdownSignalException sse,
Throwable cause) |
Modifier and Type | Field and Description |
---|---|
BlockingValueOrException<T,ShutdownSignalException> |
AMQChannel.BlockingRpcContinuation._blocker |
Modifier and Type | Method and Description |
---|---|
ShutdownSignalException |
ShutdownNotifierComponent.getCloseReason() |
ShutdownSignalException |
AMQConnection.shutdown(Method reason,
boolean initiatedByApplication,
Throwable cause,
boolean notifyRpc)
Protected API - causes all attached channels to terminate (shutdown) with a ShutdownSignal
built from the argument, and stops this connection from accepting further work from the
application.
|
Modifier and Type | Method and Description |
---|---|
Predicate<ShutdownSignalException> |
ConnectionParams.getConnectionRecoveryTriggeringCondition() |
Modifier and Type | Method and Description |
---|---|
void |
AMQChannel.RpcContinuation.handleShutdownSignal(ShutdownSignalException signal) |
void |
AMQChannel.BlockingRpcContinuation.handleShutdownSignal(ShutdownSignalException signal) |
void |
ChannelManager.handleSignal(ShutdownSignalException signal)
Handle shutdown.
|
void |
AMQChannel.notifyOutstandingRpc(ShutdownSignalException signal) |
void |
AMQChannel.processShutdownSignal(ShutdownSignalException signal,
boolean ignoreClosed,
boolean notifyRpc)
Protected API - respond, in the driver thread, to a
ShutdownSignalException . |
void |
ChannelN.processShutdownSignal(ShutdownSignalException signal,
boolean ignoreClosed,
boolean notifyRpc)
Protected API - overridden to quiesce consumer work and broadcast the signal
to all consumers after calling the superclass's method.
|
boolean |
ShutdownNotifierComponent.setShutdownCauseIfOpen(ShutdownSignalException sse)
Internal: this is the means of registering shutdown.
|
void |
RpcContinuationRpcWrapper.shutdown(ShutdownSignalException signal) |
void |
CompletableFutureRpcWrapper.shutdown(ShutdownSignalException signal) |
void |
RpcWrapper.shutdown(ShutdownSignalException signal) |
static IOException |
AMQChannel.wrap(ShutdownSignalException ex)
Placeholder until we address bug 15786 (implementing a proper exception hierarchy).
|
static IOException |
AMQChannel.wrap(ShutdownSignalException ex,
String message) |
Modifier and Type | Method and Description |
---|---|
void |
ConnectionParams.setConnectionRecoveryTriggeringCondition(Predicate<ShutdownSignalException> connectionRecoveryTriggeringCondition) |
Modifier and Type | Method and Description |
---|---|
T |
AMQChannel.BlockingRpcContinuation.getReply() |
T |
AMQChannel.BlockingRpcContinuation.getReply(int timeout) |
AMQCommand |
AMQChannel.rpc(Method m)
Protected API - sends a
Method to the broker and waits for the
next in-bound Command from the broker: only for use from
non-connection-MainLoop threads! |
AMQCommand |
AMQChannel.rpc(Method m,
int timeout) |
Modifier and Type | Field and Description |
---|---|
static Predicate<ShutdownSignalException> |
AutorecoveringConnection.DEFAULT_CONNECTION_RECOVERY_TRIGGERING_CONDITION |
Modifier and Type | Method and Description |
---|---|
ShutdownSignalException |
AutorecoveringConnection.getCloseReason() |
ShutdownSignalException |
AutorecoveringChannel.getCloseReason() |
Modifier and Type | Method and Description |
---|---|
void |
RecoveryCanBeginListener.recoveryCanBegin(ShutdownSignalException cause) |
protected boolean |
AutorecoveringConnection.shouldTriggerConnectionRecovery(ShutdownSignalException cause) |
Copyright © 2022 VMware, Inc. or its affiliates.. All rights reserved.