Package io.micronaut.rabbitmq.connect
Class RabbitConnectionFactoryConfig
java.lang.Object
com.rabbitmq.client.ConnectionFactory
io.micronaut.rabbitmq.connect.RabbitConnectionFactoryConfig
- All Implemented Interfaces:
Cloneable
- Direct Known Subclasses:
ClusterRabbitConnectionFactoryConfig,SingleRabbitConnectionFactoryConfig
public abstract class RabbitConnectionFactoryConfig
extends com.rabbitmq.client.ConnectionFactory
Base class for RabbitMQ to be configured.
- Since:
- 1.0.0
- Author:
- James Kleeh
-
Nested Class Summary
Nested ClassesModifier and TypeClassDescriptionstatic classConfiguration for the channel pool.static classConfiguration for RPC. -
Field Summary
Fields inherited from class com.rabbitmq.client.ConnectionFactory
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 Summary
Constructors -
Method Summary
Modifier and TypeMethodDescriptiongetName()getRpc()voidsetAddresses(@Nullable List<com.rabbitmq.client.Address> addresses) Sets the addresses to be passed toConnectionFactory.newConnection(List).voidsetChannelPool(@NonNull RabbitConnectionFactoryConfig.ChannelPoolConfiguration channelPool) Sets the channel pool configuration.voidsetConfirmTimeout(Duration confirmTimeout) voidsetConsumerExecutor(@NonNull String consumerExecutor) Sets the name of which executor service consumers should be executed on.voidsetRpc(@NonNull RabbitConnectionFactoryConfig.RpcConfiguration rpc) Sets the RPC configuration.Methods inherited from class com.rabbitmq.client.ConnectionFactory
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, processUriQueryParameter, setAutomaticRecoveryEnabled, setChannelRpcTimeout, setChannelShouldCheckRpcResponseType, setClientProperties, setConnectionRecoveryTriggeringCondition, setConnectionTimeout, setCredentialsProvider, setCredentialsRefreshService, setErrorOnWriteListener, setExceptionHandler, setHandshakeTimeout, setHeartbeatExecutor, setHost, setMaxInboundMessageBodySize, setMetricsCollector, setNetworkRecoveryInterval, setNetworkRecoveryInterval, setNioParams, setObservationCollector, setPassword, setPort, setRecoveredQueueNameSupplier, 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
-
Constructor Details
-
RabbitConnectionFactoryConfig
Default constructor.- Parameters:
name- The name of the configuration
-
-
Method Details
-
getName
- Returns:
- The name qualifier
-
getRpc
- Returns:
- The RPC configuration
-
setRpc
Sets the RPC configuration.- Parameters:
rpc- The RPC configuration
-
getChannelPool
- Returns:
- The channel pool configuration
-
setChannelPool
public void setChannelPool(@NonNull @NonNull RabbitConnectionFactoryConfig.ChannelPoolConfiguration channelPool) Sets the channel pool configuration.- Parameters:
channelPool- The channel pool configuration
-
getAddresses
- Returns:
- An optional list of addresses
-
setAddresses
Sets the addresses to be passed toConnectionFactory.newConnection(List).- Parameters:
addresses- The list of addresses
-
getConsumerExecutor
- Returns:
- The executor service name that consumers should be executed on
-
setConsumerExecutor
Sets the name of which executor service consumers should be executed on. Default "consumer".- Parameters:
consumerExecutor- The consumer executor service name.
-
getConfirmTimeout
- Returns:
- How long to wait for a publisher confirm
-
setConfirmTimeout
- Parameters:
confirmTimeout- How long to wait for a publisher confirm. Default value (5s).
-