Class AutorecoveringConnection
- java.lang.Object
-
- com.rabbitmq.client.impl.recovery.AutorecoveringConnection
-
- All Implemented Interfaces:
Connection
,NetworkConnection
,Recoverable
,RecoverableConnection
,ShutdownNotifier
,Closeable
,AutoCloseable
public class AutorecoveringConnection extends Object implements RecoverableConnection, NetworkConnection
Connection implementation that performs automatic recovery when connection shutdown is not initiated by the application (e.g. due to an I/O exception). Topology (exchanges, queues, bindings, and consumers) can be (and by default is) recovered as well, in this order:- Exchanges
- Queues
- Bindings (both queue and exchange-to-exchange)
- Consumers
-
-
Constructor Summary
Constructors Constructor Description AutorecoveringConnection(ConnectionParams params, FrameHandlerFactory f, AddressResolver addressResolver)
AutorecoveringConnection(ConnectionParams params, FrameHandlerFactory f, AddressResolver addressResolver, MetricsCollector metricsCollector)
AutorecoveringConnection(ConnectionParams params, FrameHandlerFactory f, List<Address> addrs)
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description void
abort()
Abort this connection and all its channels with theAMQP.REPLY_SUCCESS
close code and message 'OK'.void
abort(int timeout)
Abort this connection and all its channels with theAMQP.REPLY_SUCCESS
close code and message 'OK'.void
abort(int closeCode, String closeMessage)
Abort this connection and all its channels.void
abort(int closeCode, String closeMessage, int timeout)
Abort this connection and all its channels.void
addBlockedListener(BlockedListener listener)
Add aBlockedListener
.void
addConsumerRecoveryListener(ConsumerRecoveryListener listener)
Not part of the public API.void
addQueueRecoveryListener(QueueRecoveryListener listener)
Not part of the public API.void
addRecoveryListener(RecoveryListener listener)
Adds the recovery listenervoid
addShutdownListener(ShutdownListener listener)
Add shutdown listener.void
clearBlockedListeners()
Remove allBlockedListener
s.void
close()
Close this connection and all its channels with theAMQP.REPLY_SUCCESS
close code and message 'OK'.void
close(int timeout)
Close this connection and all its channels with theAMQP.REPLY_SUCCESS
close code and message 'OK'.void
close(int closeCode, String closeMessage)
Close this connection and all its channels.void
close(int closeCode, String closeMessage, int timeout)
Close this connection and all its channels.Channel
createChannel()
Create a new channel, using an internally allocated channel number.Channel
createChannel(int channelNumber)
Create a new channel, using the specified channel number if possible.void
excludeQueueFromRecovery(String queue, boolean ifUnused)
Exclude the queue from the list of queues to recover after connection failure.InetAddress
getAddress()
Retrieve the host.int
getChannelMax()
Get the negotiated maximum channel number.Map<String,Object>
getClientProperties()
Get a copy of the map of client properties sent to the serverString
getClientProvidedName()
Returns client-provided connection name, if any.ShutdownSignalException
getCloseReason()
Get the shutdown reason objectAMQConnection
getDelegate()
Not supposed to be used outside of automated tests.ExceptionHandler
getExceptionHandler()
Get the exception handler.int
getFrameMax()
Get the negotiated maximum frame size.int
getHeartbeat()
Get the negotiated heartbeat interval.String
getId()
Public API - Returns a unique ID for this connection.InetAddress
getLocalAddress()
Retrieve the local host.int
getLocalPort()
Retrieve the local port number.int
getPort()
Retrieve the port number.List<RecordedBinding>
getRecordedBindings()
Map<String,RecordedExchange>
getRecordedExchanges()
Map<String,RecordedQueue>
getRecordedQueues()
Map<String,Object>
getServerProperties()
Retrieve the server properties.void
init()
Private API.boolean
isOpen()
Determine whether the component is currently open.void
notifyListeners()
Protected API - notify the listeners attached to the componentvoid
recoverConsumer(String tag, RecordedConsumer consumer, boolean retry)
void
recoverQueue(String oldName, RecordedQueue q, boolean retry)
boolean
removeBlockedListener(BlockedListener listener)
Remove aBlockedListener
.void
removeConsumerRecoveryListener(ConsumerRecoveryListener listener)
void
removeQueueRecoveryListener(QueueRecoveryListener listener)
void
removeRecoveryListener(RecoveryListener listener)
Removes the recovery listenervoid
removeShutdownListener(ShutdownListener listener)
Remove shutdown listener for the component.void
setId(String id)
Public API - Sets a unique ID for this connection.protected boolean
shouldTriggerConnectionRecovery(ShutdownSignalException cause)
String
toString()
-
-
-
Constructor Detail
-
AutorecoveringConnection
public AutorecoveringConnection(ConnectionParams params, FrameHandlerFactory f, List<Address> addrs)
-
AutorecoveringConnection
public AutorecoveringConnection(ConnectionParams params, FrameHandlerFactory f, AddressResolver addressResolver)
-
AutorecoveringConnection
public AutorecoveringConnection(ConnectionParams params, FrameHandlerFactory f, AddressResolver addressResolver, MetricsCollector metricsCollector)
-
-
Method Detail
-
init
public void init() throws IOException, TimeoutException
Private API.
-
createChannel
public Channel createChannel() throws IOException
Description copied from interface:Connection
Create a new channel, using an internally allocated channel number. If automatic connection recovery is enabled, the channel returned by this method will beRecoverable
.- Specified by:
createChannel
in interfaceConnection
- Returns:
- a new channel descriptor, or null if none is available
- Throws:
IOException
- if an I/O problem is encountered- See Also:
Connection.createChannel()
-
createChannel
public Channel createChannel(int channelNumber) throws IOException
Description copied from interface:Connection
Create a new channel, using the specified channel number if possible.- Specified by:
createChannel
in interfaceConnection
- Parameters:
channelNumber
- the channel number to allocate- Returns:
- a new channel descriptor, or null if this channel number is already in use
- Throws:
IOException
- if an I/O problem is encountered- See Also:
Connection.createChannel(int)
-
getServerProperties
public Map<String,Object> getServerProperties()
Description copied from interface:Connection
Retrieve the server properties.- Specified by:
getServerProperties
in interfaceConnection
- Returns:
- a map of the server properties. This typically includes the product name and version of the server.
- See Also:
Connection.getServerProperties()
-
getClientProperties
public Map<String,Object> getClientProperties()
Description copied from interface:Connection
Get a copy of the map of client properties sent to the server- Specified by:
getClientProperties
in interfaceConnection
- Returns:
- a copy of the map of client properties
- See Also:
Connection.getClientProperties()
-
getClientProvidedName
public String getClientProvidedName()
Description copied from interface:Connection
Returns client-provided connection name, if any. Note that the value returned does not uniquely identify a connection and cannot be used as a connection identifier in HTTP API requests.- Specified by:
getClientProvidedName
in interfaceConnection
- Returns:
- client-provided connection name, if any
- See Also:
Connection.getClientProvidedName()
,ConnectionFactory.newConnection(Address[], String)
,ConnectionFactory.newConnection(ExecutorService, Address[], String)
-
getFrameMax
public int getFrameMax()
Description copied from interface:Connection
Get the negotiated maximum frame size.- Specified by:
getFrameMax
in interfaceConnection
- Returns:
- the maximum frame size, in octets; zero if unlimited
- See Also:
Connection.getFrameMax()
-
getHeartbeat
public int getHeartbeat()
Description copied from interface:Connection
Get the negotiated heartbeat interval.- Specified by:
getHeartbeat
in interfaceConnection
- Returns:
- the heartbeat interval, in seconds; zero if none
- See Also:
Connection.getHeartbeat()
-
getChannelMax
public int getChannelMax()
Description copied from interface:Connection
Get the negotiated maximum channel number. Usable channel numbers range from 1 to this number, inclusive.- Specified by:
getChannelMax
in interfaceConnection
- Returns:
- the maximum channel number permitted for this connection.
- See Also:
Connection.getChannelMax()
-
isOpen
public boolean isOpen()
Description copied from interface:ShutdownNotifier
Determine whether the component is currently open. Will return false if we are currently closing. Checking this method should be only for information, because of the race conditions - state can change after the call. Instead just execute and try to catch ShutdownSignalException and IOException- Specified by:
isOpen
in interfaceShutdownNotifier
- Returns:
- true when component is open, false otherwise
- See Also:
ShutdownNotifier.isOpen()
-
close
public void close() throws IOException
Description copied from interface:Connection
Close this connection and all its channels with theAMQP.REPLY_SUCCESS
close code and message 'OK'. Waits for all the close operations to complete.- Specified by:
close
in interfaceAutoCloseable
- Specified by:
close
in interfaceCloseable
- Specified by:
close
in interfaceConnection
- Throws:
IOException
- if an I/O problem is encountered- See Also:
Connection.close()
-
close
public void close(int timeout) throws IOException
Description copied from interface:Connection
Close this connection and all its channels with theAMQP.REPLY_SUCCESS
close code and message 'OK'. This method behaves in a similar way asConnection.close()
, with the only difference that it waits with a provided timeout for all the close operations to complete. When timeout is reached the socket is forced to close.- Specified by:
close
in interfaceConnection
- Parameters:
timeout
- timeout (in milliseconds) for completing all the close-related operations, use -1 for infinity- Throws:
IOException
- if an I/O problem is encountered- See Also:
Connection.close(int)
-
close
public void close(int closeCode, String closeMessage, int timeout) throws IOException
Description copied from interface:Connection
Close this connection and all its channels. Waits with the given timeout for all the close operations to complete. When timeout is reached the socket is forced to close.- Specified by:
close
in interfaceConnection
- Parameters:
closeCode
- the close code (See under "Reply Codes" in the AMQP specification)closeMessage
- a message indicating the reason for closing the connectiontimeout
- timeout (in milliseconds) for completing all the close-related operations, use -1 for infinity- Throws:
IOException
- if an I/O problem is encountered- See Also:
Connection.close(int, String, int)
-
abort
public void abort()
Description copied from interface:Connection
Abort this connection and all its channels with theAMQP.REPLY_SUCCESS
close code and message 'OK'. Forces the connection to close. Any encountered exceptions in the close operations are silently discarded.- Specified by:
abort
in interfaceConnection
- See Also:
Connection.abort()
-
abort
public void abort(int closeCode, String closeMessage, int timeout)
Description copied from interface:Connection
Abort this connection and all its channels. Forces the connection to close and waits with the given timeout for all the close operations to complete. When timeout is reached the socket is forced to close. Any encountered exceptions in the close operations are silently discarded.- Specified by:
abort
in interfaceConnection
- Parameters:
closeCode
- the close code (See under "Reply Codes" in the AMQP specification)closeMessage
- a message indicating the reason for closing the connectiontimeout
- timeout (in milliseconds) for completing all the close-related operations, use -1 for infinity- See Also:
Connection.abort(int, String, int)
-
abort
public void abort(int closeCode, String closeMessage)
Description copied from interface:Connection
Abort this connection and all its channels. Forces the connection to close and waits for all the close operations to complete. Any encountered exceptions in the close operations are silently discarded.- Specified by:
abort
in interfaceConnection
- Parameters:
closeCode
- the close code (See under "Reply Codes" in the AMQP specification)closeMessage
- a message indicating the reason for closing the connection- See Also:
Connection.abort(int, String)
-
abort
public void abort(int timeout)
Description copied from interface:Connection
Abort this connection and all its channels with theAMQP.REPLY_SUCCESS
close code and message 'OK'. This method behaves in a similar way asConnection.abort()
, with the only difference that it waits with a provided timeout for all the close operations to complete. When timeout is reached the socket is forced to close.- Specified by:
abort
in interfaceConnection
- Parameters:
timeout
- timeout (in milliseconds) for completing all the close-related operations, use -1 for infinity- See Also:
Connection.abort(int)
-
getDelegate
public AMQConnection getDelegate()
Not supposed to be used outside of automated tests.
-
getCloseReason
public ShutdownSignalException getCloseReason()
Description copied from interface:ShutdownNotifier
Get the shutdown reason object- Specified by:
getCloseReason
in interfaceShutdownNotifier
- Returns:
- ShutdownSignalException if component is closed, null otherwise
- See Also:
ShutdownNotifier.getCloseReason()
-
addBlockedListener
public void addBlockedListener(BlockedListener listener)
Description copied from interface:Connection
Add aBlockedListener
.- Specified by:
addBlockedListener
in interfaceConnection
- Parameters:
listener
- the listener to add- See Also:
ShutdownNotifier.addShutdownListener(com.rabbitmq.client.ShutdownListener)
-
removeBlockedListener
public boolean removeBlockedListener(BlockedListener listener)
Description copied from interface:Connection
Remove aBlockedListener
.- Specified by:
removeBlockedListener
in interfaceConnection
- Parameters:
listener
- the listener to remove- Returns:
true
if the listener was found and removed,false
otherwise- See Also:
Connection.removeBlockedListener(com.rabbitmq.client.BlockedListener)
-
clearBlockedListeners
public void clearBlockedListeners()
Description copied from interface:Connection
Remove allBlockedListener
s.- Specified by:
clearBlockedListeners
in interfaceConnection
- See Also:
Connection.clearBlockedListeners()
-
close
public void close(int closeCode, String closeMessage) throws IOException
Description copied from interface:Connection
Close this connection and all its channels. Waits for all the close operations to complete.- Specified by:
close
in interfaceConnection
- Parameters:
closeCode
- the close code (See under "Reply Codes" in the AMQP specification)closeMessage
- a message indicating the reason for closing the connection- Throws:
IOException
- if an I/O problem is encountered- See Also:
Connection.close(int, String)
-
addShutdownListener
public void addShutdownListener(ShutdownListener listener)
Description copied from interface:ShutdownNotifier
Add shutdown listener. If the component is already closed, handler is fired immediately- Specified by:
addShutdownListener
in interfaceShutdownNotifier
- Parameters:
listener
-ShutdownListener
to the component- See Also:
ShutdownNotifier.addShutdownListener(com.rabbitmq.client.ShutdownListener)
-
removeShutdownListener
public void removeShutdownListener(ShutdownListener listener)
Description copied from interface:ShutdownNotifier
Remove shutdown listener for the component.- Specified by:
removeShutdownListener
in interfaceShutdownNotifier
- Parameters:
listener
-ShutdownListener
to be removed- See Also:
ShutdownNotifier.removeShutdownListener(com.rabbitmq.client.ShutdownListener)
-
notifyListeners
public void notifyListeners()
Description copied from interface:ShutdownNotifier
Protected API - notify the listeners attached to the component- Specified by:
notifyListeners
in interfaceShutdownNotifier
- See Also:
ShutdownNotifier.notifyListeners()
-
addRecoveryListener
public void addRecoveryListener(RecoveryListener listener)
Adds the recovery listener- Specified by:
addRecoveryListener
in interfaceRecoverable
- Parameters:
listener
-RecoveryListener
to execute after this connection recovers from network failure
-
removeRecoveryListener
public void removeRecoveryListener(RecoveryListener listener)
Removes the recovery listener- Specified by:
removeRecoveryListener
in interfaceRecoverable
- Parameters:
listener
-RecoveryListener
to remove
-
getExceptionHandler
public ExceptionHandler getExceptionHandler()
Description copied from interface:Connection
Get the exception handler.- Specified by:
getExceptionHandler
in interfaceConnection
- See Also:
AMQConnection.getExceptionHandler()
-
getPort
public int getPort()
Description copied from interface:Connection
Retrieve the port number.- Specified by:
getPort
in interfaceConnection
- Specified by:
getPort
in interfaceNetworkConnection
- Returns:
- the port number of the peer we're connected to.
- See Also:
Connection.getPort()
-
getAddress
public InetAddress getAddress()
Description copied from interface:Connection
Retrieve the host.- Specified by:
getAddress
in interfaceConnection
- Specified by:
getAddress
in interfaceNetworkConnection
- Returns:
- the hostname of the peer we're connected to.
- See Also:
Connection.getAddress()
-
getLocalAddress
public InetAddress getLocalAddress()
Description copied from interface:NetworkConnection
Retrieve the local host.- Specified by:
getLocalAddress
in interfaceNetworkConnection
- Returns:
- client socket address
-
getLocalPort
public int getLocalPort()
Description copied from interface:NetworkConnection
Retrieve the local port number.- Specified by:
getLocalPort
in interfaceNetworkConnection
- Returns:
- client socket port
-
shouldTriggerConnectionRecovery
protected boolean shouldTriggerConnectionRecovery(ShutdownSignalException cause)
-
addQueueRecoveryListener
public void addQueueRecoveryListener(QueueRecoveryListener listener)
Not part of the public API. Mean to be used by JVM RabbitMQ clients that build on top of the Java client and need to be notified when server-named queue name changes after recovery.- Parameters:
listener
- listener that observes queue name changes after recovery
-
removeQueueRecoveryListener
public void removeQueueRecoveryListener(QueueRecoveryListener listener)
- Parameters:
listener
- listener to be removed- See Also:
addQueueRecoveryListener(com.rabbitmq.client.impl.recovery.QueueRecoveryListener)
-
addConsumerRecoveryListener
public void addConsumerRecoveryListener(ConsumerRecoveryListener listener)
Not part of the public API. Mean to be used by JVM RabbitMQ clients that build on top of the Java client and need to be notified when consumer tag changes after recovery.- Parameters:
listener
- listener that observes consumer tag changes after recovery
-
removeConsumerRecoveryListener
public void removeConsumerRecoveryListener(ConsumerRecoveryListener listener)
- Parameters:
listener
- listener to be removed- See Also:
addConsumerRecoveryListener(ConsumerRecoveryListener)
-
recoverQueue
public void recoverQueue(String oldName, RecordedQueue q, boolean retry)
-
recoverConsumer
public void recoverConsumer(String tag, RecordedConsumer consumer, boolean retry)
-
excludeQueueFromRecovery
public void excludeQueueFromRecovery(String queue, boolean ifUnused)
Exclude the queue from the list of queues to recover after connection failure. Intended to be used in usecases where you want to remove the queue from this connection's recovery list but don't want to delete the queue from the server.- Parameters:
queue
- queue name to exclude from recorded recovery queuesifUnused
- if true, the RecordedQueue will only be excluded if no local consumers are using it.
-
getRecordedQueues
public Map<String,RecordedQueue> getRecordedQueues()
-
getRecordedExchanges
public Map<String,RecordedExchange> getRecordedExchanges()
-
getRecordedBindings
public List<RecordedBinding> getRecordedBindings()
-
getId
public String getId()
Public API - Returns a unique ID for this connection. This ID must be unique, otherwise some services like the metrics collector won't work properly. This ID doesn't have to be provided by the client, services that require it will be assigned automatically if not set.- Specified by:
getId
in interfaceConnection
- Returns:
- unique ID for this connection.
-
setId
public void setId(String id)
Public API - Sets a unique ID for this connection. This ID must be unique, otherwise some services like the metrics collector won't work properly. This ID doesn't have to be provided by the client, services that require it will be assigned automatically if not set.- Specified by:
setId
in interfaceConnection
-
-