Class ConnectionFactory
- java.lang.Object
-
- com.rabbitmq.client.ConnectionFactory
-
- All Implemented Interfaces:
Cloneable
public class ConnectionFactory extends Object implements Cloneable
Convenience "factory" class to facilitate opening aConnection
to an AMQP broker.
-
-
Field Summary
Fields Modifier and Type Field Description static int
DEFAULT_AMQP_OVER_SSL_PORT
The default ssl portstatic int
DEFAULT_AMQP_PORT
The default non-ssl portstatic int
DEFAULT_CHANNEL_MAX
Default maximum channel number; 2047 because it's 2048 on the server side minus channel 0, which each connection uses for negotiation and error communicationstatic int
DEFAULT_CHANNEL_RPC_TIMEOUT
The default continuation timeout for RPC calls in channels: 10 minutesstatic int
DEFAULT_CONNECTION_TIMEOUT
The default TCP connection timeout: 60 secondsstatic int
DEFAULT_FRAME_MAX
Default maximum frame size; zero means no limitstatic int
DEFAULT_HANDSHAKE_TIMEOUT
The default AMQP 0-9-1 connection handshake timeout.static int
DEFAULT_HEARTBEAT
Default heart-beat interval; 60 secondsstatic String
DEFAULT_HOST
The default hoststatic long
DEFAULT_NETWORK_RECOVERY_INTERVAL
The default network recovery interval: 5000 millisstatic String
DEFAULT_PASS
Default passwordstatic int
DEFAULT_SHUTDOWN_TIMEOUT
The default shutdown timeout; zero means wait indefinitelystatic String
DEFAULT_USER
Default user namestatic String
DEFAULT_VHOST
Default virtual hoststatic int
DEFAULT_WORK_POOL_TIMEOUT
The default timeout for work pool enqueueing: no timeoutstatic int
USE_DEFAULT_PORT
'Use the default port' port
-
Constructor Summary
Constructors Constructor Description ConnectionFactory()
-
Method Summary
All Methods Static Methods Instance Methods Concrete Methods Modifier and Type Method Description ConnectionFactory
clone()
static String
computeDefaultTlsProtocol(String[] supportedProtocols)
protected AddressResolver
createAddressResolver(List<Address> addresses)
protected AMQConnection
createConnection(ConnectionParams params, FrameHandler frameHandler, MetricsCollector metricsCollector)
protected FrameHandlerFactory
createFrameHandlerFactory()
void
enableHostnameVerification()
Enable server hostname verification for TLS connections.void
enableHostnameVerification(HostnameVerifier hostnameVerifier)
Enable TLS hostname verification performed by the passed-inHostnameVerifier
.protected void
enableHostnameVerificationForBlockingIo()
protected void
enableHostnameVerificationForNio()
static int
ensureUnsignedShort(int value)
int
getChannelRpcTimeout()
Get the timeout for RPC calls in channels.Map<String,Object>
getClientProperties()
Retrieve the currently-configured table of client properties that will be sent to the server during connection startup.int
getConnectionTimeout()
Retrieve the TCP connection timeout.ExceptionHandler
getExceptionHandler()
Get the exception handler.int
getHandshakeTimeout()
Retrieve the AMQP 0-9-1 protocol handshake timeout.String
getHost()
MetricsCollector
getMetricsCollector()
long
getNetworkRecoveryInterval()
Returns automatic connection recovery interval in milliseconds.NioParams
getNioParams()
Retrieve the parameters for NIO mode.String
getPassword()
Retrieve the password.int
getPort()
RecoveryDelayHandler
getRecoveryDelayHandler()
Returns automatic connection recovery delay handler.int
getRequestedChannelMax()
Retrieve the requested maximum channel numberint
getRequestedFrameMax()
Retrieve the requested maximum frame sizeint
getRequestedHeartbeat()
Retrieve the requested heartbeat interval.SaslConfig
getSaslConfig()
Gets the sasl config to use when authenticatingint
getShutdownTimeout()
Retrieve the shutdown timeout.SocketConfigurator
getSocketConfigurator()
Get the socket configurator.SocketFactory
getSocketFactory()
Retrieve the socket factory used to make connections with.ThreadFactory
getThreadFactory()
Retrieve the thread factory used to instantiate new threads.ExecutorService
getTopologyRecoveryExecutor()
Get the executor to use for parallel topology recovery.String
getUsername()
Retrieve the user name.String
getVirtualHost()
Retrieve the virtual host.int
getWorkPoolTimeout()
boolean
isAutomaticRecoveryEnabled()
Returns true if automatic connection recovery is enabled, false otherwiseboolean
isChannelShouldCheckRpcResponseType()
protected boolean
isJava6()
boolean
isSSL()
boolean
isTopologyRecoveryEnabled()
Returns true if topology recovery is enabled, false otherwiseConnectionFactory
load(String propertyFileLocation)
Load settings from a property file.ConnectionFactory
load(String propertyFileLocation, String prefix)
Load settings from a property file.ConnectionFactory
load(Map<String,String> properties)
Load settings from aMap
instance.ConnectionFactory
load(Map<String,String> properties, String prefix)
Load settings from aMap
instance.ConnectionFactory
load(Properties properties)
Load settings from aProperties
instance.ConnectionFactory
load(Properties properties, String prefix)
Load settings from aProperties
instance.Connection
newConnection()
Create a new broker connection.Connection
newConnection(Address[] addrs)
Create a new broker connection, picking the first available address from the list.Connection
newConnection(Address[] addrs, String clientProvidedName)
Create a new broker connection with a client-provided name, picking the first available address from the list.Connection
newConnection(AddressResolver addressResolver)
Create a new broker connection, picking the first available address from the list provided by theAddressResolver
.Connection
newConnection(String connectionName)
Create a new broker connection.Connection
newConnection(ExecutorService executor)
Create a new broker connection.Connection
newConnection(ExecutorService executor, Address[] addrs)
Create a new broker connection, picking the first available address from the list.Connection
newConnection(ExecutorService executor, Address[] addrs, String clientProvidedName)
Create a new broker connection with a client-provided name, picking the first available address from the list.Connection
newConnection(ExecutorService executor, AddressResolver addressResolver)
Create a new broker connection, picking the first available address from the list provided by theAddressResolver
.Connection
newConnection(ExecutorService executor, AddressResolver addressResolver, String clientProvidedName)
Create a new broker connection with a client-provided name, picking the first available address from the list provided by theAddressResolver
.Connection
newConnection(ExecutorService executor, String connectionName)
Create a new broker connection.Connection
newConnection(ExecutorService executor, List<Address> addrs)
Create a new broker connection, picking the first available address from the list.Connection
newConnection(ExecutorService executor, List<Address> addrs, String clientProvidedName)
Create a new broker connection with a client-provided name, picking the first available address from the list.Connection
newConnection(List<Address> addrs)
Create a new broker connection, picking the first available address from the list.Connection
newConnection(List<Address> addrs, String clientProvidedName)
Create a new broker connection with a client-provided name, picking the first available address from the list.ConnectionParams
params(ExecutorService consumerWorkServiceExecutor)
static int
portOrDefault(int port, boolean ssl)
void
setAutomaticRecoveryEnabled(boolean automaticRecovery)
Enables or disables automatic connection recovery.void
setChannelRpcTimeout(int channelRpcTimeout)
Set the continuation timeout for RPC calls in channels.void
setChannelShouldCheckRpcResponseType(boolean channelShouldCheckRpcResponseType)
When set to true, channels will check the response type (e.g.void
setClientProperties(Map<String,Object> clientProperties)
Replace the table of client properties that will be sent to the server during subsequent connection startups.void
setConnectionPostProcessor(ConnectionPostProcessor connectionPostProcessor)
Hook to post-process the freshly open TCP connection.void
setConnectionTimeout(int timeout)
Set the TCP connection timeout.void
setCredentialsProvider(CredentialsProvider credentialsProvider)
Set a custom credentials provider.void
setErrorOnWriteListener(ErrorOnWriteListener errorOnWriteListener)
Set a listener to be called when connection gets an IO error trying to write on the socket.void
setExceptionHandler(ExceptionHandler exceptionHandler)
Set the exception handler to use for newly created connections.void
setHandshakeTimeout(int timeout)
Set the AMQP0-9-1 protocol handshake timeout.void
setHeartbeatExecutor(ScheduledExecutorService executor)
Set the executor to use to send heartbeat frames.void
setHost(String host)
void
setMetricsCollector(MetricsCollector metricsCollector)
void
setNetworkRecoveryInterval(int networkRecoveryInterval)
Sets connection recovery interval.void
setNetworkRecoveryInterval(long networkRecoveryInterval)
Sets connection recovery interval.void
setNioParams(NioParams nioParams)
Sets the parameters when using NIO.void
setPassword(String password)
Set the password.void
setPort(int port)
Set the target port.void
setRecoveryDelayHandler(RecoveryDelayHandler recoveryDelayHandler)
Sets the automatic connection recovery delay handler.void
setRequestedChannelMax(int requestedChannelMax)
Set the requested maximum channel number.void
setRequestedFrameMax(int requestedFrameMax)
Set the requested maximum frame sizevoid
setRequestedHeartbeat(int requestedHeartbeat)
Set the requested heartbeat timeout.void
setSaslConfig(SaslConfig saslConfig)
Sets the sasl config to use when authenticatingvoid
setSharedExecutor(ExecutorService executor)
Set the executor to use for consumer operation dispatch by default for newly created connections.void
setShutdownExecutor(ExecutorService executor)
Set the executor to use for connection shutdown.void
setShutdownTimeout(int shutdownTimeout)
Set the shutdown timeout.void
setSocketConfigurator(SocketConfigurator socketConfigurator)
Set the socket configurator.void
setSocketFactory(SocketFactory factory)
Set the socket factory used to make connections with.void
setThreadFactory(ThreadFactory threadFactory)
Set the thread factory used to instantiate new threads.void
setTopologyRecoveryEnabled(boolean topologyRecovery)
Enables or disables topology recoveryvoid
setTopologyRecoveryExecutor(ExecutorService topologyRecoveryExecutor)
Set the executor to use for parallel topology recovery.void
setTopologyRecoveryFilter(TopologyRecoveryFilter topologyRecoveryFilter)
Set filter to include/exclude entities from topology recovery.void
setTopologyRecoveryRetryHandler(RetryHandler topologyRecoveryRetryHandler)
Set retry handler for topology recovery.void
setTrafficListener(TrafficListener trafficListener)
Traffic listener notified of inbound and outboundCommand
s.void
setUri(String uriString)
Convenience method for setting the fields in an AMQP URI: host, port, username, password and virtual host.void
setUri(URI uri)
Convenience method for setting the fields in an AMQP URI: host, port, username, password and virtual host.void
setUsername(String username)
Set the user name.void
setVirtualHost(String virtualHost)
Set the virtual host.void
setWorkPoolTimeout(int workPoolTimeout)
Timeout (in ms) for work pool enqueueing.void
useBlockingIo()
Use blocking IO for communication with the server.void
useNio()
Use non-blocking IO (NIO) for communication with the server.void
useSslProtocol()
Convenience method for configuring TLS using the default set of TLS protocols and a trusting TrustManager.void
useSslProtocol(String protocol)
Convenience method for configuring TLS using the supplied protocol and a very trusting TrustManager.void
useSslProtocol(String protocol, TrustManager trustManager)
Convenience method for configuring TLS.void
useSslProtocol(SSLContext context)
Sets up TLS with an initializedSSLContext
.
-
-
-
Field Detail
-
DEFAULT_USER
public static final String DEFAULT_USER
Default user name- See Also:
- Constant Field Values
-
DEFAULT_PASS
public static final String DEFAULT_PASS
Default password- See Also:
- Constant Field Values
-
DEFAULT_VHOST
public static final String DEFAULT_VHOST
Default virtual host- See Also:
- Constant Field Values
-
DEFAULT_CHANNEL_MAX
public static final int DEFAULT_CHANNEL_MAX
Default maximum channel number; 2047 because it's 2048 on the server side minus channel 0, which each connection uses for negotiation and error communication- See Also:
- Constant Field Values
-
DEFAULT_FRAME_MAX
public static final int DEFAULT_FRAME_MAX
Default maximum frame size; zero means no limit- See Also:
- Constant Field Values
-
DEFAULT_HEARTBEAT
public static final int DEFAULT_HEARTBEAT
Default heart-beat interval; 60 seconds- See Also:
- Constant Field Values
-
DEFAULT_HOST
public static final String DEFAULT_HOST
The default host- See Also:
- Constant Field Values
-
USE_DEFAULT_PORT
public static final int USE_DEFAULT_PORT
'Use the default port' port- See Also:
- Constant Field Values
-
DEFAULT_AMQP_PORT
public static final int DEFAULT_AMQP_PORT
The default non-ssl port- See Also:
- Constant Field Values
-
DEFAULT_AMQP_OVER_SSL_PORT
public static final int DEFAULT_AMQP_OVER_SSL_PORT
The default ssl port- See Also:
- Constant Field Values
-
DEFAULT_CONNECTION_TIMEOUT
public static final int DEFAULT_CONNECTION_TIMEOUT
The default TCP connection timeout: 60 seconds- See Also:
- Constant Field Values
-
DEFAULT_HANDSHAKE_TIMEOUT
public static final int DEFAULT_HANDSHAKE_TIMEOUT
The default AMQP 0-9-1 connection handshake timeout. See DEFAULT_CONNECTION_TIMEOUT for TCP (socket) connection timeout.- See Also:
- Constant Field Values
-
DEFAULT_SHUTDOWN_TIMEOUT
public static final int DEFAULT_SHUTDOWN_TIMEOUT
The default shutdown timeout; zero means wait indefinitely- See Also:
- Constant Field Values
-
DEFAULT_CHANNEL_RPC_TIMEOUT
public static final int DEFAULT_CHANNEL_RPC_TIMEOUT
The default continuation timeout for RPC calls in channels: 10 minutes
-
DEFAULT_NETWORK_RECOVERY_INTERVAL
public static final long DEFAULT_NETWORK_RECOVERY_INTERVAL
The default network recovery interval: 5000 millis- See Also:
- Constant Field Values
-
DEFAULT_WORK_POOL_TIMEOUT
public static final int DEFAULT_WORK_POOL_TIMEOUT
The default timeout for work pool enqueueing: no timeout- See Also:
- Constant Field Values
-
-
Method Detail
-
getHost
public String getHost()
- Returns:
- the default host to use for connections
-
setHost
public void setHost(String host)
- Parameters:
host
- the default host to use for connections
-
portOrDefault
public static int portOrDefault(int port, boolean ssl)
-
getPort
public int getPort()
- Returns:
- the default port to use for connections
-
setPort
public void setPort(int port)
Set the target port.- Parameters:
port
- the default port to use for connections
-
getUsername
public String getUsername()
Retrieve the user name.- Returns:
- the AMQP user name to use when connecting to the broker
-
setUsername
public void setUsername(String username)
Set the user name.- Parameters:
username
- the AMQP user name to use when connecting to the broker
-
getPassword
public String getPassword()
Retrieve the password.- Returns:
- the password to use when connecting to the broker
-
setPassword
public void setPassword(String password)
Set the password.- Parameters:
password
- the password to use when connecting to the broker
-
setCredentialsProvider
public void setCredentialsProvider(CredentialsProvider credentialsProvider)
Set a custom credentials provider. Default implementation uses static username and password.- Parameters:
credentialsProvider
- The custom implementation of CredentialsProvider to use when connecting to the broker.- Since:
- 4.5.0
- See Also:
DefaultCredentialsProvider
-
getVirtualHost
public String getVirtualHost()
Retrieve the virtual host.- Returns:
- the virtual host to use when connecting to the broker
-
setVirtualHost
public void setVirtualHost(String virtualHost)
Set the virtual host.- Parameters:
virtualHost
- the virtual host to use when connecting to the broker
-
setUri
public void setUri(URI uri) throws URISyntaxException, NoSuchAlgorithmException, KeyManagementException
Convenience method for setting the fields in an AMQP URI: host, port, username, password and virtual host. If any part of the URI is omitted, the ConnectionFactory's corresponding variable is left unchanged.- Parameters:
uri
- is the AMQP URI containing the data- Throws:
URISyntaxException
NoSuchAlgorithmException
KeyManagementException
-
setUri
public void setUri(String uriString) throws URISyntaxException, NoSuchAlgorithmException, KeyManagementException
Convenience method for setting the fields in an AMQP URI: host, port, username, password and virtual host. If any part of the URI is omitted, the ConnectionFactory's corresponding variable is left unchanged. Note that not all valid AMQP URIs are accepted; in particular, the hostname must be given if the port, username or password are given, and escapes in the hostname are not permitted.- Parameters:
uriString
- is the AMQP URI containing the data- Throws:
URISyntaxException
NoSuchAlgorithmException
KeyManagementException
-
getRequestedChannelMax
public int getRequestedChannelMax()
Retrieve the requested maximum channel number- Returns:
- the initially requested maximum channel number; zero for unlimited
-
setRequestedChannelMax
public void setRequestedChannelMax(int requestedChannelMax)
Set the requested maximum channel number.Note the value must be between 0 and 65535 (unsigned short in AMQP 0-9-1).
- Parameters:
requestedChannelMax
- initially requested maximum channel number; zero for unlimited
-
getRequestedFrameMax
public int getRequestedFrameMax()
Retrieve the requested maximum frame size- Returns:
- the initially requested maximum frame size, in octets; zero for unlimited
-
setRequestedFrameMax
public void setRequestedFrameMax(int requestedFrameMax)
Set the requested maximum frame size- Parameters:
requestedFrameMax
- initially requested maximum frame size, in octets; zero for unlimited
-
getRequestedHeartbeat
public int getRequestedHeartbeat()
Retrieve the requested heartbeat interval.- Returns:
- the initially requested heartbeat interval, in seconds; zero for none
-
setConnectionTimeout
public void setConnectionTimeout(int timeout)
Set the TCP connection timeout.- Parameters:
timeout
- connection TCP establishment timeout in milliseconds; zero for infinite
-
getConnectionTimeout
public int getConnectionTimeout()
Retrieve the TCP connection timeout.- Returns:
- the TCP connection timeout, in milliseconds; zero for infinite
-
getHandshakeTimeout
public int getHandshakeTimeout()
Retrieve the AMQP 0-9-1 protocol handshake timeout.- Returns:
- the AMQP0-9-1 protocol handshake timeout, in milliseconds
-
setHandshakeTimeout
public void setHandshakeTimeout(int timeout)
Set the AMQP0-9-1 protocol handshake timeout.- Parameters:
timeout
- the AMQP0-9-1 protocol handshake timeout, in milliseconds
-
setShutdownTimeout
public void setShutdownTimeout(int shutdownTimeout)
Set the shutdown timeout. This is the amount of time that Consumer implementations have to continue working through deliveries (and other Consumer callbacks) after the connection has closed but before the ConsumerWorkService is torn down. If consumers exceed this timeout then any remaining queued deliveries (and other Consumer callbacks, including the Consumer's handleShutdownSignal() invocation) will be lost.- Parameters:
shutdownTimeout
- shutdown timeout in milliseconds; zero for infinite; default 10000
-
getShutdownTimeout
public int getShutdownTimeout()
Retrieve the shutdown timeout.- Returns:
- the shutdown timeout, in milliseconds; zero for infinite
-
setRequestedHeartbeat
public void setRequestedHeartbeat(int requestedHeartbeat)
Set the requested heartbeat timeout. Heartbeat frames will be sent at about 1/2 the timeout interval. If server heartbeat timeout is configured to a non-zero value, this method can only be used to lower the value; otherwise any value provided by the client will be used.Note the value must be between 0 and 65535 (unsigned short in AMQP 0-9-1).
- Parameters:
requestedHeartbeat
- the initially requested heartbeat timeout, in seconds; zero for none- See Also:
- RabbitMQ Heartbeats Guide
-
getClientProperties
public Map<String,Object> getClientProperties()
Retrieve the currently-configured table of client properties that will be sent to the server during connection startup. Clients may add, delete, and alter keys in this table. Such changes will take effect when the next new connection is started using this factory.- Returns:
- the map of client properties
- See Also:
setClientProperties(java.util.Map<java.lang.String, java.lang.Object>)
-
setClientProperties
public void setClientProperties(Map<String,Object> clientProperties)
Replace the table of client properties that will be sent to the server during subsequent connection startups.- Parameters:
clientProperties
- the map of extra client properties- See Also:
getClientProperties()
-
getSaslConfig
public SaslConfig getSaslConfig()
Gets the sasl config to use when authenticating- Returns:
- the sasl config
- See Also:
SaslConfig
-
setSaslConfig
public void setSaslConfig(SaslConfig saslConfig)
Sets the sasl config to use when authenticating- Parameters:
saslConfig
-- See Also:
SaslConfig
-
getSocketFactory
public SocketFactory getSocketFactory()
Retrieve the socket factory used to make connections with.
-
setSocketFactory
public void setSocketFactory(SocketFactory factory)
Set the socket factory used to make connections with. Can be used to enable SSL connections by passing in a javax.net.ssl.SSLSocketFactory instance.- See Also:
useSslProtocol()
-
getSocketConfigurator
public SocketConfigurator getSocketConfigurator()
Get the socket configurator.
-
setSocketConfigurator
public void setSocketConfigurator(SocketConfigurator socketConfigurator)
Set the socket configurator. This gets a chance to "configure" a socket before it has been opened. The default socket configurator disables Nagle's algorithm.- Parameters:
socketConfigurator
- the configurator to use
-
setSharedExecutor
public void setSharedExecutor(ExecutorService executor)
Set the executor to use for consumer operation dispatch by default for newly created connections. All connections that use this executor share it. It's developer's responsibility to shut down the executor when it is no longer needed.- Parameters:
executor
- executor service to be used for consumer operation
-
setShutdownExecutor
public void setShutdownExecutor(ExecutorService executor)
Set the executor to use for connection shutdown. All connections that use this executor share it. It's developer's responsibility to shut down the executor when it is no longer needed.- Parameters:
executor
- executor service to be used for connection shutdown
-
setHeartbeatExecutor
public void setHeartbeatExecutor(ScheduledExecutorService executor)
Set the executor to use to send heartbeat frames. All connections that use this executor share it. It's developer's responsibility to shut down the executor when it is no longer needed.- Parameters:
executor
- executor service to be used to send heartbeat
-
getThreadFactory
public ThreadFactory getThreadFactory()
Retrieve the thread factory used to instantiate new threads.- See Also:
ThreadFactory
-
setThreadFactory
public void setThreadFactory(ThreadFactory threadFactory)
Set the thread factory used to instantiate new threads.- See Also:
ThreadFactory
-
getExceptionHandler
public ExceptionHandler getExceptionHandler()
Get the exception handler.- See Also:
ExceptionHandler
-
setExceptionHandler
public void setExceptionHandler(ExceptionHandler exceptionHandler)
Set the exception handler to use for newly created connections.- See Also:
ExceptionHandler
-
isSSL
public boolean isSSL()
-
useSslProtocol
public void useSslProtocol() throws NoSuchAlgorithmException, KeyManagementException
Convenience method for configuring TLS using the default set of TLS protocols and a trusting TrustManager. This setup is only suitable for development and QA environments. The trust manager will trust every server certificate presented to it, this is convenient for local development but not recommended to use in production as it provides no protection against man-in-the-middle attacks. PreferuseSslProtocol(SSLContext)
.
-
useSslProtocol
public void useSslProtocol(String protocol) throws NoSuchAlgorithmException, KeyManagementException
Convenience method for configuring TLS using the supplied protocol and a very trusting TrustManager. This setup is only suitable for development and QA environments. The trust manager will trust every server certificate presented to it, this is convenient for local development but not recommended to use in production as it provides no protection against man-in-the-middle attacks. UseuseSslProtocol(SSLContext)
in production environments. The producedSSLContext
instance will be shared by all the connections created by this connection factory.
-
useSslProtocol
public void useSslProtocol(String protocol, TrustManager trustManager) throws NoSuchAlgorithmException, KeyManagementException
Convenience method for configuring TLS. Pass in the TLS protocol version to use, e.g. "TLSv1.2" or "TLSv1.1", and a desiredTrustManager
. Note you must explicitly enable hostname verification with theenableHostnameVerification()
or theenableHostnameVerification(HostnameVerifier)
method. The producedSSLContext
instance will be shared with all the connections created by this connection factory.- Parameters:
protocol
- the TLS protocol to use.trustManager
- theTrustManager
implementation to use.- Throws:
NoSuchAlgorithmException
KeyManagementException
- See Also:
useSslProtocol(SSLContext)
,enableHostnameVerification()
,enableHostnameVerification(HostnameVerifier)
-
useSslProtocol
public void useSslProtocol(SSLContext context)
Sets up TLS with an initializedSSLContext
. The caller is responsible for setting up the context with aTrustManager
with suitable security guarantees, e.g. peer verification. Note you must explicitly enable hostname verification with theenableHostnameVerification()
or theenableHostnameVerification(HostnameVerifier)
method. TheSSLContext
instance will be shared with all the connections created by this connection factory.- Parameters:
context
- An initialized SSLContext- See Also:
enableHostnameVerification()
,enableHostnameVerification(HostnameVerifier)
-
enableHostnameVerification
public void enableHostnameVerification()
Enable server hostname verification for TLS connections.This enables hostname verification regardless of the IO mode used (blocking or non-blocking IO).
This can be called typically after setting the
SSLContext
with one of theuseSslProtocol
methods.If using Java 7 or more, the hostname verification will be performed by Java, as part of the TLS handshake.
If using Java 6, the hostname verification will be handled after the TLS handshake, using the
HostnameVerifier
from the Commons HttpClient project. This requires to add Commons HttpClient and its dependencies to the classpath. To use a customHostnameVerifier
, useenableHostnameVerification(HostnameVerifier)
.- Since:
- 4.8.0
- See Also:
NioParams.enableHostnameVerification()
,NioParams.setSslEngineConfigurator(SslEngineConfigurator)
,SslEngineConfigurators.ENABLE_HOSTNAME_VERIFICATION
,SocketConfigurators.ENABLE_HOSTNAME_VERIFICATION
,useSslProtocol(String)
,useSslProtocol(SSLContext)
,useSslProtocol()
,useSslProtocol(String, TrustManager)
,enableHostnameVerification(HostnameVerifier)
-
enableHostnameVerification
public void enableHostnameVerification(HostnameVerifier hostnameVerifier)
Enable TLS hostname verification performed by the passed-inHostnameVerifier
.Using an
HostnameVerifier
is relevant only for Java 6, for Java 7 or more, calling ConnectionFactoryenableHostnameVerification()
is enough.- Parameters:
hostnameVerifier
-- Since:
- 4.8.0
- See Also:
enableHostnameVerification()
-
isJava6
protected boolean isJava6()
-
enableHostnameVerificationForNio
protected void enableHostnameVerificationForNio()
-
enableHostnameVerificationForBlockingIo
protected void enableHostnameVerificationForBlockingIo()
-
computeDefaultTlsProtocol
public static String computeDefaultTlsProtocol(String[] supportedProtocols)
-
isAutomaticRecoveryEnabled
public boolean isAutomaticRecoveryEnabled()
Returns true if automatic connection recovery is enabled, false otherwise- Returns:
- true if automatic connection recovery is enabled, false otherwise
- See Also:
- Automatic Recovery
-
setAutomaticRecoveryEnabled
public void setAutomaticRecoveryEnabled(boolean automaticRecovery)
Enables or disables automatic connection recovery.- Parameters:
automaticRecovery
- if true, enables connection recovery- See Also:
- Automatic Recovery
-
isTopologyRecoveryEnabled
public boolean isTopologyRecoveryEnabled()
Returns true if topology recovery is enabled, false otherwise- Returns:
- true if topology recovery is enabled, false otherwise
- See Also:
- Automatic Recovery
-
setTopologyRecoveryEnabled
public void setTopologyRecoveryEnabled(boolean topologyRecovery)
Enables or disables topology recovery- Parameters:
topologyRecovery
- if true, enables topology recovery- See Also:
- Automatic Recovery
-
getTopologyRecoveryExecutor
public ExecutorService getTopologyRecoveryExecutor()
Get the executor to use for parallel topology recovery. If null (the default), recovery is done single threaded on the main connection thread.- Returns:
- thread pool executor
- Since:
- 4.7.0
-
setTopologyRecoveryExecutor
public void setTopologyRecoveryExecutor(ExecutorService topologyRecoveryExecutor)
Set the executor to use for parallel topology recovery. If null (the default), recovery is done single threaded on the main connection thread. It is recommended to pass a ThreadPoolExecutor that will allow its core threads to timeout so these threads can die when recovery is complete. It's developer's responsibility to shut down the executor when it is no longer needed. Note: yourExceptionHandler.handleTopologyRecoveryException(Connection, Channel, TopologyRecoveryException)
method should be thread-safe.- Parameters:
topologyRecoveryExecutor
- thread pool executor- Since:
- 4.7.0
-
setMetricsCollector
public void setMetricsCollector(MetricsCollector metricsCollector)
-
getMetricsCollector
public MetricsCollector getMetricsCollector()
-
createFrameHandlerFactory
protected FrameHandlerFactory createFrameHandlerFactory() throws IOException
- Throws:
IOException
-
newConnection
public Connection newConnection(Address[] addrs) throws IOException, TimeoutException
Create a new broker connection, picking the first available address from the list. If automatic connection recovery is enabled, the connection returned by this method will beRecoverable
. Future reconnection attempts will pick a random accessible address from the provided list.- Parameters:
addrs
- an array of known broker addresses (hostname/port pairs) to try in order- Returns:
- an interface to the connection
- Throws:
IOException
- if it encounters a problemTimeoutException
-
newConnection
public Connection newConnection(AddressResolver addressResolver) throws IOException, TimeoutException
Create a new broker connection, picking the first available address from the list provided by theAddressResolver
. If automatic connection recovery is enabled, the connection returned by this method will beRecoverable
. Future reconnection attempts will pick a random accessible address provided by theAddressResolver
.- Parameters:
addressResolver
- discovery service to list potential addresses (hostname/port pairs) to connect to- Returns:
- an interface to the connection
- Throws:
IOException
- if it encounters a problemTimeoutException
- See Also:
- Automatic Recovery
-
newConnection
public Connection newConnection(Address[] addrs, String clientProvidedName) throws IOException, TimeoutException
Create a new broker connection with a client-provided name, picking the first available address from the list. If automatic connection recovery is enabled, the connection returned by this method will beRecoverable
. Future reconnection attempts will pick a random accessible address from the provided list.- Parameters:
addrs
- an array of known broker addresses (hostname/port pairs) to try in orderclientProvidedName
- application-specific connection name, will be displayed in the management UI if RabbitMQ server supports it. This value doesn't have to be unique and cannot be used as a connection identifier e.g. in HTTP API requests. This value is supposed to be human-readable.- Returns:
- an interface to the connection
- Throws:
IOException
- if it encounters a problemTimeoutException
-
newConnection
public Connection newConnection(List<Address> addrs) throws IOException, TimeoutException
Create a new broker connection, picking the first available address from the list. If automatic connection recovery is enabled, the connection returned by this method will beRecoverable
. Future reconnection attempts will pick a random accessible address from the provided list.- Parameters:
addrs
- a List of known broker addresses (hostname/port pairs) to try in order- Returns:
- an interface to the connection
- Throws:
IOException
- if it encounters a problemTimeoutException
-
newConnection
public Connection newConnection(List<Address> addrs, String clientProvidedName) throws IOException, TimeoutException
Create a new broker connection with a client-provided name, picking the first available address from the list. If automatic connection recovery is enabled, the connection returned by this method will beRecoverable
. Future reconnection attempts will pick a random accessible address from the provided list.- Parameters:
addrs
- a List of known broker addresses (hostname/port pairs) to try in orderclientProvidedName
- application-specific connection name, will be displayed in the management UI if RabbitMQ server supports it. This value doesn't have to be unique and cannot be used as a connection identifier e.g. in HTTP API requests. This value is supposed to be human-readable.- Returns:
- an interface to the connection
- Throws:
IOException
- if it encounters a problemTimeoutException
-
newConnection
public Connection newConnection(ExecutorService executor, Address[] addrs) throws IOException, TimeoutException
Create a new broker connection, picking the first available address from the list. If automatic connection recovery is enabled, the connection returned by this method will beRecoverable
. Future reconnection attempts will pick a random accessible address from the provided list.- Parameters:
executor
- thread execution service for consumers on the connectionaddrs
- an array of known broker addresses (hostname/port pairs) to try in order- Returns:
- an interface to the connection
- Throws:
IOException
- if it encounters a problemTimeoutException
- See Also:
- Automatic Recovery
-
newConnection
public Connection newConnection(ExecutorService executor, Address[] addrs, String clientProvidedName) throws IOException, TimeoutException
Create a new broker connection with a client-provided name, picking the first available address from the list. If automatic connection recovery is enabled, the connection returned by this method will beRecoverable
. Future reconnection attempts will pick a random accessible address from the provided list.- Parameters:
executor
- thread execution service for consumers on the connectionaddrs
- an array of known broker addresses (hostname/port pairs) to try in orderclientProvidedName
- application-specific connection name, will be displayed in the management UI if RabbitMQ server supports it. This value doesn't have to be unique and cannot be used as a connection identifier e.g. in HTTP API requests. This value is supposed to be human-readable.- Returns:
- an interface to the connection
- Throws:
IOException
- if it encounters a problemTimeoutException
- See Also:
- Automatic Recovery
-
newConnection
public Connection newConnection(ExecutorService executor, List<Address> addrs) throws IOException, TimeoutException
Create a new broker connection, picking the first available address from the list. If automatic connection recovery is enabled, the connection returned by this method will beRecoverable
. Future reconnection attempts will pick a random accessible address from the provided list.- Parameters:
executor
- thread execution service for consumers on the connectionaddrs
- a List of known broker addrs (hostname/port pairs) to try in order- Returns:
- an interface to the connection
- Throws:
IOException
- if it encounters a problemTimeoutException
- See Also:
- Automatic Recovery
-
newConnection
public Connection newConnection(ExecutorService executor, AddressResolver addressResolver) throws IOException, TimeoutException
Create a new broker connection, picking the first available address from the list provided by theAddressResolver
. If automatic connection recovery is enabled, the connection returned by this method will beRecoverable
. Future reconnection attempts will pick a random accessible address provided by theAddressResolver
.- Parameters:
executor
- thread execution service for consumers on the connectionaddressResolver
- discovery service to list potential addresses (hostname/port pairs) to connect to- Returns:
- an interface to the connection
- Throws:
IOException
- if it encounters a problemTimeoutException
- See Also:
- Automatic Recovery
-
newConnection
public Connection newConnection(ExecutorService executor, List<Address> addrs, String clientProvidedName) throws IOException, TimeoutException
Create a new broker connection with a client-provided name, picking the first available address from the list. If automatic connection recovery is enabled, the connection returned by this method will beRecoverable
. Future reconnection attempts will pick a random accessible address from the provided list.- Parameters:
executor
- thread execution service for consumers on the connectionaddrs
- a List of known broker addrs (hostname/port pairs) to try in orderclientProvidedName
- application-specific connection name, will be displayed in the management UI if RabbitMQ server supports it. This value doesn't have to be unique and cannot be used as a connection identifier e.g. in HTTP API requests. This value is supposed to be human-readable.- Returns:
- an interface to the connection
- Throws:
IOException
- if it encounters a problemTimeoutException
- See Also:
- Automatic Recovery
-
newConnection
public Connection newConnection(ExecutorService executor, AddressResolver addressResolver, String clientProvidedName) throws IOException, TimeoutException
Create a new broker connection with a client-provided name, picking the first available address from the list provided by theAddressResolver
. If automatic connection recovery is enabled, the connection returned by this method will beRecoverable
. Future reconnection attempts will pick a random accessible address provided by theAddressResolver
.- Parameters:
executor
- thread execution service for consumers on the connectionaddressResolver
- discovery service to list potential addresses (hostname/port pairs) to connect toclientProvidedName
- application-specific connection name, will be displayed in the management UI if RabbitMQ server supports it. This value doesn't have to be unique and cannot be used as a connection identifier e.g. in HTTP API requests. This value is supposed to be human-readable.- Returns:
- an interface to the connection
- Throws:
IOException
- if it encounters a problemTimeoutException
- See Also:
- Automatic Recovery
-
params
public ConnectionParams params(ExecutorService consumerWorkServiceExecutor)
-
createConnection
protected AMQConnection createConnection(ConnectionParams params, FrameHandler frameHandler, MetricsCollector metricsCollector)
-
newConnection
public Connection newConnection() throws IOException, TimeoutException
Create a new broker connection. If automatic connection recovery is enabled, the connection returned by this method will beRecoverable
. Reconnection attempts will always use the address configured onConnectionFactory
.- Returns:
- an interface to the connection
- Throws:
IOException
- if it encounters a problemTimeoutException
-
newConnection
public Connection newConnection(String connectionName) throws IOException, TimeoutException
Create a new broker connection. If automatic connection recovery is enabled, the connection returned by this method will beRecoverable
. Reconnection attempts will always use the address configured onConnectionFactory
.- Parameters:
connectionName
- client-provided connection name (an arbitrary string). Will be displayed in management UI if the server supports it.- Returns:
- an interface to the connection
- Throws:
IOException
- if it encounters a problemTimeoutException
-
newConnection
public Connection newConnection(ExecutorService executor) throws IOException, TimeoutException
Create a new broker connection. If automatic connection recovery is enabled, the connection returned by this method will beRecoverable
. Reconnection attempts will always use the address configured onConnectionFactory
.- Parameters:
executor
- thread execution service for consumers on the connection- Returns:
- an interface to the connection
- Throws:
IOException
- if it encounters a problemTimeoutException
-
newConnection
public Connection newConnection(ExecutorService executor, String connectionName) throws IOException, TimeoutException
Create a new broker connection. If automatic connection recovery is enabled, the connection returned by this method will beRecoverable
. Reconnection attempts will always use the address configured onConnectionFactory
.- Parameters:
executor
- thread execution service for consumers on the connectionconnectionName
- client-provided connection name (an arbitrary string). Will be displayed in management UI if the server supports it.- Returns:
- an interface to the connection
- Throws:
IOException
- if it encounters a problemTimeoutException
-
createAddressResolver
protected AddressResolver createAddressResolver(List<Address> addresses)
-
clone
public ConnectionFactory clone()
-
load
public ConnectionFactory load(String propertyFileLocation) throws IOException
Load settings from a property file. Keys must be prefixed withrabbitmq.
, useload(String, String)
to specify your own prefix.- Parameters:
propertyFileLocation
- location of the property file to use- Throws:
IOException
- when something goes wrong reading the file- Since:
- 4.4.0
- See Also:
ConnectionFactoryConfigurator
-
load
public ConnectionFactory load(String propertyFileLocation, String prefix) throws IOException
Load settings from a property file.- Parameters:
propertyFileLocation
- location of the property file to useprefix
- key prefix for the entries in the file- Throws:
IOException
- when something goes wrong reading the file- Since:
- 4.4.0
- See Also:
ConnectionFactoryConfigurator
-
load
public ConnectionFactory load(Properties properties)
Load settings from aProperties
instance. Keys must be prefixed withrabbitmq.
, useload(Properties, String)
to specify your own prefix.- Parameters:
properties
- source for settings- Since:
- 4.4.0
- See Also:
ConnectionFactoryConfigurator
-
load
public ConnectionFactory load(Properties properties, String prefix)
Load settings from aProperties
instance.- Parameters:
properties
- source for settingsprefix
- key prefix for properties entries- Since:
- 4.4.0
- See Also:
ConnectionFactoryConfigurator
-
load
public ConnectionFactory load(Map<String,String> properties)
Load settings from aMap
instance. Keys must be prefixed withrabbitmq.
, useload(Map, String)
to specify your own prefix.- Parameters:
properties
- source for settings- Since:
- 4.4.0
- See Also:
ConnectionFactoryConfigurator
-
load
public ConnectionFactory load(Map<String,String> properties, String prefix)
Load settings from aMap
instance.- Parameters:
properties
- source for settingsprefix
- key prefix for map entries- Since:
- 4.4.0
- See Also:
ConnectionFactoryConfigurator
-
getNetworkRecoveryInterval
public long getNetworkRecoveryInterval()
Returns automatic connection recovery interval in milliseconds.- Returns:
- how long will automatic recovery wait before attempting to reconnect, in ms; default is 5000
-
setNetworkRecoveryInterval
public void setNetworkRecoveryInterval(int networkRecoveryInterval)
Sets connection recovery interval. Default is 5000. UsesRecoveryDelayHandler.DefaultRecoveryDelayHandler
by default. Use anotherRecoveryDelayHandler
implementation for more flexibility.- Parameters:
networkRecoveryInterval
- how long will automatic recovery wait before attempting to reconnect, in ms- See Also:
RecoveryDelayHandler
-
setNetworkRecoveryInterval
public void setNetworkRecoveryInterval(long networkRecoveryInterval)
Sets connection recovery interval. Default is 5000. UsesRecoveryDelayHandler.DefaultRecoveryDelayHandler
by default. Use anotherRecoveryDelayHandler
implementation for more flexibility.- Parameters:
networkRecoveryInterval
- how long will automatic recovery wait before attempting to reconnect, in ms- See Also:
RecoveryDelayHandler
-
getRecoveryDelayHandler
public RecoveryDelayHandler getRecoveryDelayHandler()
Returns automatic connection recovery delay handler.- Returns:
- recovery delay handler. May be null if not set.
- Since:
- 4.3.0
-
setRecoveryDelayHandler
public void setRecoveryDelayHandler(RecoveryDelayHandler recoveryDelayHandler)
Sets the automatic connection recovery delay handler.- Parameters:
recoveryDelayHandler
- the recovery delay handler- Since:
- 4.3.0
-
setNioParams
public void setNioParams(NioParams nioParams)
Sets the parameters when using NIO.- Parameters:
nioParams
-- See Also:
NioParams
-
getNioParams
public NioParams getNioParams()
Retrieve the parameters for NIO mode.- Returns:
-
useNio
public void useNio()
Use non-blocking IO (NIO) for communication with the server. With NIO, several connections created from the sameConnectionFactory
can use the same IO thread. A client process using a lot of not-so-active connections can benefit from NIO, as it would use fewer threads than with the traditional, blocking IO mode. UseNioParams
to tune NIO and aSocketChannelConfigurator
to configure the underlyingSocketChannel
s for connections.- See Also:
NioParams
,SocketChannelConfigurator
,SocketChannel
,Selector
-
useBlockingIo
public void useBlockingIo()
Use blocking IO for communication with the server. With blocking IO, each connection creates its own thread to read data from the server.
-
setChannelRpcTimeout
public void setChannelRpcTimeout(int channelRpcTimeout)
Set the continuation timeout for RPC calls in channels. Default is 10 minutes. 0 means no timeout.- Parameters:
channelRpcTimeout
-
-
getChannelRpcTimeout
public int getChannelRpcTimeout()
Get the timeout for RPC calls in channels.- Returns:
-
setChannelShouldCheckRpcResponseType
public void setChannelShouldCheckRpcResponseType(boolean channelShouldCheckRpcResponseType)
When set to true, channels will check the response type (e.g. queue.declare expects a queue.declare-ok response) of RPC calls and ignore those that do not match. Default is false.- Parameters:
channelShouldCheckRpcResponseType
-
-
isChannelShouldCheckRpcResponseType
public boolean isChannelShouldCheckRpcResponseType()
-
setWorkPoolTimeout
public void setWorkPoolTimeout(int workPoolTimeout)
Timeout (in ms) for work pool enqueueing. TheWorkPool
dispatches several types of responses from the broker (e.g. deliveries). A high-traffic client with slow consumers can exhaust the work pool and compromise the whole connection (by e.g. letting the broker saturate the receive TCP buffers). Setting a timeout would make the connection fail early and avoid hard-to-diagnose TCP connection failure. Note this shouldn't happen with clients that set appropriate QoS values. Default is no timeout.- Parameters:
workPoolTimeout
- timeout in ms- Since:
- 4.5.0
-
getWorkPoolTimeout
public int getWorkPoolTimeout()
-
setErrorOnWriteListener
public void setErrorOnWriteListener(ErrorOnWriteListener errorOnWriteListener)
Set a listener to be called when connection gets an IO error trying to write on the socket. Default listener triggers connection recovery asynchronously and propagates the exception. Override the default listener to disable or customise automatic connection triggering on write operations.- Parameters:
errorOnWriteListener
- the listener- Since:
- 4.5.0
-
setTopologyRecoveryFilter
public void setTopologyRecoveryFilter(TopologyRecoveryFilter topologyRecoveryFilter)
Set filter to include/exclude entities from topology recovery.- Since:
- 4.8.0
-
setTopologyRecoveryRetryHandler
public void setTopologyRecoveryRetryHandler(RetryHandler topologyRecoveryRetryHandler)
Set retry handler for topology recovery. Default is no retry.- Parameters:
topologyRecoveryRetryHandler
-- Since:
- 4.8.0
-
setConnectionPostProcessor
public void setConnectionPostProcessor(ConnectionPostProcessor connectionPostProcessor)
Hook to post-process the freshly open TCP connection.- Parameters:
connectionPostProcessor
-- See Also:
enableHostnameVerification()
,enableHostnameVerification(HostnameVerifier)
-
setTrafficListener
public void setTrafficListener(TrafficListener trafficListener)
Traffic listener notified of inbound and outboundCommand
s.Useful for debugging purposes, e.g. logging all sent and received messages. Default is no-op.
- Parameters:
trafficListener
-- Since:
- 4.9.0
- See Also:
TrafficListener
,LogTrafficListener
-
ensureUnsignedShort
public static int ensureUnsignedShort(int value)
-
-