Class ClusterRabbitConnectionFactoryConfig

java.lang.Object
com.rabbitmq.client.ConnectionFactory
io.micronaut.rabbitmq.connect.RabbitConnectionFactoryConfig
io.micronaut.rabbitmq.connect.ClusterRabbitConnectionFactoryConfig
All Implemented Interfaces:
Cloneable

@Requires(property="rabbitmq.servers") @EachProperty("rabbitmq.servers") public class ClusterRabbitConnectionFactoryConfig extends RabbitConnectionFactoryConfig
Allows configuration of multiple RabbitMQ connections.
Since:
1.1.0
Author:
James Kleeh
  • Nested Class Summary

    Nested Classes
  • Field Summary

    Fields
    Modifier and Type
    Field
    Description
    static final String
     

    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
    Constructor
    Description
    Default constructor.
  • Method Summary

    Modifier and Type
    Method
    Description
    void
    Sets the channel pool configuration.
    void
    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

    Methods inherited from class java.lang.Object

    equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait