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 voidabort()Abort this connection and all its channels with theAMQP.REPLY_SUCCESSclose code and message 'OK'.voidabort(int timeout)Abort this connection and all its channels with theAMQP.REPLY_SUCCESSclose code and message 'OK'.voidabort(int closeCode, String closeMessage)Abort this connection and all its channels.voidabort(int closeCode, String closeMessage, int timeout)Abort this connection and all its channels.voidaddBlockedListener(BlockedListener listener)Add aBlockedListener.voidaddConsumerRecoveryListener(ConsumerRecoveryListener listener)Not part of the public API.voidaddQueueRecoveryListener(QueueRecoveryListener listener)Not part of the public API.voidaddRecoveryListener(RecoveryListener listener)Adds the recovery listenervoidaddShutdownListener(ShutdownListener listener)Add shutdown listener.voidclearBlockedListeners()Remove allBlockedListeners.voidclose()Close this connection and all its channels with theAMQP.REPLY_SUCCESSclose code and message 'OK'.voidclose(int timeout)Close this connection and all its channels with theAMQP.REPLY_SUCCESSclose code and message 'OK'.voidclose(int closeCode, String closeMessage)Close this connection and all its channels.voidclose(int closeCode, String closeMessage, int timeout)Close this connection and all its channels.ChannelcreateChannel()Create a new channel, using an internally allocated channel number.ChannelcreateChannel(int channelNumber)Create a new channel, using the specified channel number if possible.voidexcludeQueueFromRecovery(String queue, boolean ifUnused)Exclude the queue from the list of queues to recover after connection failure.InetAddressgetAddress()Retrieve the host.intgetChannelMax()Get the negotiated maximum channel number.Map<String,Object>getClientProperties()Get a copy of the map of client properties sent to the serverStringgetClientProvidedName()Returns client-provided connection name, if any.ShutdownSignalExceptiongetCloseReason()Get the shutdown reason objectAMQConnectiongetDelegate()Not supposed to be used outside of automated tests.ExceptionHandlergetExceptionHandler()Get the exception handler.intgetFrameMax()Get the negotiated maximum frame size.intgetHeartbeat()Get the negotiated heartbeat interval.StringgetId()Public API - Returns a unique ID for this connection.InetAddressgetLocalAddress()Retrieve the local host.intgetLocalPort()Retrieve the local port number.intgetPort()Retrieve the port number.List<RecordedBinding>getRecordedBindings()Map<String,RecordedExchange>getRecordedExchanges()Map<String,RecordedQueue>getRecordedQueues()Map<String,Object>getServerProperties()Retrieve the server properties.voidinit()Private API.booleanisOpen()Determine whether the component is currently open.voidnotifyListeners()Protected API - notify the listeners attached to the componentvoidrecoverConsumer(String tag, RecordedConsumer consumer, boolean retry)voidrecoverQueue(String oldName, RecordedQueue q, boolean retry)booleanremoveBlockedListener(BlockedListener listener)Remove aBlockedListener.voidremoveConsumerRecoveryListener(ConsumerRecoveryListener listener)voidremoveQueueRecoveryListener(QueueRecoveryListener listener)voidremoveRecoveryListener(RecoveryListener listener)Removes the recovery listenervoidremoveShutdownListener(ShutdownListener listener)Remove shutdown listener for the component.voidsetId(String id)Public API - Sets a unique ID for this connection.protected booleanshouldTriggerConnectionRecovery(ShutdownSignalException cause)StringtoString()
-
-
-
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, TimeoutExceptionPrivate API.
-
createChannel
public Channel createChannel() throws IOException
Description copied from interface:ConnectionCreate 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:
createChannelin 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:ConnectionCreate a new channel, using the specified channel number if possible.- Specified by:
createChannelin 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:ConnectionRetrieve the server properties.- Specified by:
getServerPropertiesin 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:ConnectionGet a copy of the map of client properties sent to the server- Specified by:
getClientPropertiesin interfaceConnection- Returns:
- a copy of the map of client properties
- See Also:
Connection.getClientProperties()
-
getClientProvidedName
public String getClientProvidedName()
Description copied from interface:ConnectionReturns 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:
getClientProvidedNamein 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:ConnectionGet the negotiated maximum frame size.- Specified by:
getFrameMaxin interfaceConnection- Returns:
- the maximum frame size, in octets; zero if unlimited
- See Also:
Connection.getFrameMax()
-
getHeartbeat
public int getHeartbeat()
Description copied from interface:ConnectionGet the negotiated heartbeat interval.- Specified by:
getHeartbeatin interfaceConnection- Returns:
- the heartbeat interval, in seconds; zero if none
- See Also:
Connection.getHeartbeat()
-
getChannelMax
public int getChannelMax()
Description copied from interface:ConnectionGet the negotiated maximum channel number. Usable channel numbers range from 1 to this number, inclusive.- Specified by:
getChannelMaxin interfaceConnection- Returns:
- the maximum channel number permitted for this connection.
- See Also:
Connection.getChannelMax()
-
isOpen
public boolean isOpen()
Description copied from interface:ShutdownNotifierDetermine 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:
isOpenin interfaceShutdownNotifier- Returns:
- true when component is open, false otherwise
- See Also:
ShutdownNotifier.isOpen()
-
close
public void close() throws IOExceptionDescription copied from interface:ConnectionClose this connection and all its channels with theAMQP.REPLY_SUCCESSclose code and message 'OK'. Waits for all the close operations to complete.- Specified by:
closein interfaceAutoCloseable- Specified by:
closein interfaceCloseable- Specified by:
closein interfaceConnection- Throws:
IOException- if an I/O problem is encountered- See Also:
Connection.close()
-
close
public void close(int timeout) throws IOExceptionDescription copied from interface:ConnectionClose this connection and all its channels with theAMQP.REPLY_SUCCESSclose 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:
closein 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 IOExceptionDescription copied from interface:ConnectionClose 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:
closein 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:ConnectionAbort this connection and all its channels with theAMQP.REPLY_SUCCESSclose code and message 'OK'. Forces the connection to close. Any encountered exceptions in the close operations are silently discarded.- Specified by:
abortin interfaceConnection- See Also:
Connection.abort()
-
abort
public void abort(int closeCode, String closeMessage, int timeout)Description copied from interface:ConnectionAbort 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:
abortin 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:ConnectionAbort 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:
abortin 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:ConnectionAbort this connection and all its channels with theAMQP.REPLY_SUCCESSclose 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:
abortin 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:ShutdownNotifierGet the shutdown reason object- Specified by:
getCloseReasonin interfaceShutdownNotifier- Returns:
- ShutdownSignalException if component is closed, null otherwise
- See Also:
ShutdownNotifier.getCloseReason()
-
addBlockedListener
public void addBlockedListener(BlockedListener listener)
Description copied from interface:ConnectionAdd aBlockedListener.- Specified by:
addBlockedListenerin 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:ConnectionRemove aBlockedListener.- Specified by:
removeBlockedListenerin interfaceConnection- Parameters:
listener- the listener to remove- Returns:
trueif the listener was found and removed,falseotherwise- See Also:
Connection.removeBlockedListener(com.rabbitmq.client.BlockedListener)
-
clearBlockedListeners
public void clearBlockedListeners()
Description copied from interface:ConnectionRemove allBlockedListeners.- Specified by:
clearBlockedListenersin interfaceConnection- See Also:
Connection.clearBlockedListeners()
-
close
public void close(int closeCode, String closeMessage) throws IOExceptionDescription copied from interface:ConnectionClose this connection and all its channels. Waits for all the close operations to complete.- Specified by:
closein 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:ShutdownNotifierAdd shutdown listener. If the component is already closed, handler is fired immediately- Specified by:
addShutdownListenerin interfaceShutdownNotifier- Parameters:
listener-ShutdownListenerto the component- See Also:
ShutdownNotifier.addShutdownListener(com.rabbitmq.client.ShutdownListener)
-
removeShutdownListener
public void removeShutdownListener(ShutdownListener listener)
Description copied from interface:ShutdownNotifierRemove shutdown listener for the component.- Specified by:
removeShutdownListenerin interfaceShutdownNotifier- Parameters:
listener-ShutdownListenerto be removed- See Also:
ShutdownNotifier.removeShutdownListener(com.rabbitmq.client.ShutdownListener)
-
notifyListeners
public void notifyListeners()
Description copied from interface:ShutdownNotifierProtected API - notify the listeners attached to the component- Specified by:
notifyListenersin interfaceShutdownNotifier- See Also:
ShutdownNotifier.notifyListeners()
-
addRecoveryListener
public void addRecoveryListener(RecoveryListener listener)
Adds the recovery listener- Specified by:
addRecoveryListenerin interfaceRecoverable- Parameters:
listener-RecoveryListenerto execute after this connection recovers from network failure
-
removeRecoveryListener
public void removeRecoveryListener(RecoveryListener listener)
Removes the recovery listener- Specified by:
removeRecoveryListenerin interfaceRecoverable- Parameters:
listener-RecoveryListenerto remove
-
getExceptionHandler
public ExceptionHandler getExceptionHandler()
Description copied from interface:ConnectionGet the exception handler.- Specified by:
getExceptionHandlerin interfaceConnection- See Also:
AMQConnection.getExceptionHandler()
-
getPort
public int getPort()
Description copied from interface:ConnectionRetrieve the port number.- Specified by:
getPortin interfaceConnection- Specified by:
getPortin interfaceNetworkConnection- Returns:
- the port number of the peer we're connected to.
- See Also:
Connection.getPort()
-
getAddress
public InetAddress getAddress()
Description copied from interface:ConnectionRetrieve the host.- Specified by:
getAddressin interfaceConnection- Specified by:
getAddressin interfaceNetworkConnection- Returns:
- the hostname of the peer we're connected to.
- See Also:
Connection.getAddress()
-
getLocalAddress
public InetAddress getLocalAddress()
Description copied from interface:NetworkConnectionRetrieve the local host.- Specified by:
getLocalAddressin interfaceNetworkConnection- Returns:
- client socket address
-
getLocalPort
public int getLocalPort()
Description copied from interface:NetworkConnectionRetrieve the local port number.- Specified by:
getLocalPortin 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:
getIdin 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:
setIdin interfaceConnection
-
-