public abstract class RabbitConnectionFactoryConfig
extends com.rabbitmq.client.ConnectionFactory
Modifier and Type | Class and Description |
---|---|
static class |
RabbitConnectionFactoryConfig.ChannelPoolConfiguration
Configuration for the channel pool.
|
static class |
RabbitConnectionFactoryConfig.RpcConfiguration
Configuration for RPC.
|
DEFAULT_AMQP_OVER_SSL_PORT, DEFAULT_AMQP_PORT, DEFAULT_CHANNEL_MAX, DEFAULT_CHANNEL_RPC_TIMEOUT, DEFAULT_CONNECTION_TIMEOUT, DEFAULT_FRAME_MAX, DEFAULT_HANDSHAKE_TIMEOUT, DEFAULT_HEARTBEAT, DEFAULT_HOST, DEFAULT_NETWORK_RECOVERY_INTERVAL, DEFAULT_PASS, DEFAULT_SHUTDOWN_TIMEOUT, DEFAULT_USER, DEFAULT_VHOST, DEFAULT_WORK_POOL_TIMEOUT, USE_DEFAULT_PORT
Constructor and Description |
---|
RabbitConnectionFactoryConfig(String name)
Default constructor.
|
Modifier and Type | Method and Description |
---|---|
Optional<List<com.rabbitmq.client.Address>> |
getAddresses() |
RabbitConnectionFactoryConfig.ChannelPoolConfiguration |
getChannelPool() |
String |
getConsumerExecutor() |
String |
getName() |
RabbitConnectionFactoryConfig.RpcConfiguration |
getRpc() |
void |
setAddresses(List<com.rabbitmq.client.Address> addresses)
Sets the addresses to be passed to
ConnectionFactory.newConnection(List) . |
void |
setChannelPool(RabbitConnectionFactoryConfig.ChannelPoolConfiguration channelPool)
Sets the channel pool configuration.
|
void |
setConsumerExecutor(String consumerExecutor)
Sets the name of which executor service consumers should be executed on.
|
void |
setRpc(RabbitConnectionFactoryConfig.RpcConfiguration rpc)
Sets the RPC configuration.
|
clone, computeDefaultTlsProtocol, createAddressResolver, createConnection, createFrameHandlerFactory, enableHostnameVerification, enableHostnameVerificationForBlockingIo, enableHostnameVerificationForNio, ensureUnsignedShort, getChannelRpcTimeout, getClientProperties, getConnectionTimeout, getExceptionHandler, getHandshakeTimeout, getHost, getMetricsCollector, getNetworkRecoveryInterval, getNioParams, getPassword, getPort, getRecoveryDelayHandler, getRequestedChannelMax, getRequestedFrameMax, getRequestedHeartbeat, getSaslConfig, getShutdownTimeout, getSocketConfigurator, getSocketFactory, getThreadFactory, getTopologyRecoveryExecutor, getUsername, getVirtualHost, getWorkPoolTimeout, isAutomaticRecoveryEnabled, isChannelShouldCheckRpcResponseType, isSSL, isTopologyRecoveryEnabled, load, load, load, load, load, load, newConnection, newConnection, newConnection, newConnection, newConnection, newConnection, newConnection, newConnection, newConnection, newConnection, newConnection, newConnection, newConnection, newConnection, newConnection, params, portOrDefault, setAutomaticRecoveryEnabled, setChannelRpcTimeout, setChannelShouldCheckRpcResponseType, setClientProperties, setConnectionRecoveryTriggeringCondition, setConnectionTimeout, setCredentialsProvider, setCredentialsRefreshService, setErrorOnWriteListener, setExceptionHandler, setHandshakeTimeout, setHeartbeatExecutor, setHost, setMetricsCollector, setNetworkRecoveryInterval, setNetworkRecoveryInterval, setNioParams, setPassword, setPort, setRecoveryDelayHandler, setRequestedChannelMax, setRequestedFrameMax, setRequestedHeartbeat, setSaslConfig, setSharedExecutor, setShutdownExecutor, setShutdownTimeout, setSocketConfigurator, setSocketFactory, setSslContextFactory, setThreadFactory, setTopologyRecoveryEnabled, setTopologyRecoveryExecutor, setTopologyRecoveryFilter, setTopologyRecoveryRetryHandler, setTrafficListener, setUri, setUri, setUsername, setVirtualHost, setWorkPoolTimeout, useBlockingIo, useNio, useSslProtocol, useSslProtocol, useSslProtocol, useSslProtocol
public RabbitConnectionFactoryConfig(@Parameter String name)
name
- The name of the configurationpublic String getName()
public RabbitConnectionFactoryConfig.RpcConfiguration getRpc()
public void setRpc(@Nonnull RabbitConnectionFactoryConfig.RpcConfiguration rpc)
rpc
- The RPC configurationpublic RabbitConnectionFactoryConfig.ChannelPoolConfiguration getChannelPool()
public void setChannelPool(@Nonnull RabbitConnectionFactoryConfig.ChannelPoolConfiguration channelPool)
channelPool
- The channel pool configurationpublic Optional<List<com.rabbitmq.client.Address>> getAddresses()
public void setAddresses(@Nullable List<com.rabbitmq.client.Address> addresses)
ConnectionFactory.newConnection(List)
.addresses
- The list of addressespublic String getConsumerExecutor()