public class RMQConnectionConfig extends Object implements Serializable
RMQConnectionConfig.Builder.setUri(String)
has been set then RMQConnectionConfig(String, Integer, Boolean, Boolean, Integer, Integer,
Integer, Integer, Integer, Long)
will be used for initialize the RMQ connection or RMQConnectionConfig(String, Integer, String, String, String, Integer,
Boolean, Boolean, Integer, Integer, Integer, Integer, Integer, Long)
will be used for initialize
the RMQ connectionModifier and Type | Class and Description |
---|---|
static class |
RMQConnectionConfig.Builder
The Builder Class for
RMQConnectionConfig . |
Modifier and Type | Method and Description |
---|---|
com.rabbitmq.client.ConnectionFactory |
getConnectionFactory() |
Integer |
getConnectionTimeout()
Retrieve the connection timeout.
|
long |
getDeliveryTimeout()
Retrieve the message delivery timeout used in the queueing consumer.
|
String |
getHost() |
Integer |
getNetworkRecoveryInterval()
Returns automatic connection recovery interval in milliseconds.
|
String |
getPassword()
Retrieve the password.
|
int |
getPort() |
Optional<Integer> |
getPrefetchCount()
Retrieve the the channel prefetch count.
|
Integer |
getRequestedChannelMax()
Retrieve the requested maximum channel number.
|
Integer |
getRequestedFrameMax()
Retrieve the requested maximum frame size.
|
Integer |
getRequestedHeartbeat()
Retrieve the requested heartbeat interval.
|
String |
getUri()
Retrieve the URI.
|
String |
getUsername()
Retrieve the user name.
|
String |
getVirtualHost()
Retrieve the virtual host.
|
Boolean |
isAutomaticRecovery()
Returns true if automatic connection recovery is enabled, false otherwise.
|
Boolean |
isTopologyRecovery()
Returns true if topology recovery is enabled, false otherwise.
|
public String getHost()
public int getPort()
public String getVirtualHost()
public String getUsername()
public String getPassword()
public String getUri()
public Integer getNetworkRecoveryInterval()
public Boolean isAutomaticRecovery()
public Boolean isTopologyRecovery()
public Integer getConnectionTimeout()
public Integer getRequestedChannelMax()
public Integer getRequestedFrameMax()
public Integer getRequestedHeartbeat()
public Optional<Integer> getPrefetchCount()
public long getDeliveryTimeout()
public com.rabbitmq.client.ConnectionFactory getConnectionFactory() throws URISyntaxException, NoSuchAlgorithmException, KeyManagementException
URISyntaxException
- if Malformed URI has been passedNoSuchAlgorithmException
- if the ssl factory could not be createdKeyManagementException
- if the ssl context could not be initializedCopyright © 2014–2021 The Apache Software Foundation. All rights reserved.