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 Classes
    Modifier and Type
    Class
    Description
    static class 
    Configuration for the channel pool.
    static class 
    Configuration 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
    Constructor
    Description
    Default constructor.
  • Method Summary

    Modifier and Type
    Method
    Description
    Optional<List<com.rabbitmq.client.Address>>
     
     
     
     
     
     
    void
    setAddresses(@Nullable List<com.rabbitmq.client.Address> addresses)
    Sets the addresses to be passed to ConnectionFactory.newConnection(List).
    void
    Sets the channel pool configuration.
    void
    setConfirmTimeout(Duration confirmTimeout)
     
    void
    setConsumerExecutor(@NonNull String consumerExecutor)
    Sets the name of which executor service consumers should be executed on.
    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
  • Constructor Details

    • RabbitConnectionFactoryConfig

      public RabbitConnectionFactoryConfig(@Parameter String name)
      Default constructor.
      Parameters:
      name - The name of the configuration
  • Method Details

    • getName

      public String getName()
      Returns:
      The name qualifier
    • getRpc

      Returns:
      The RPC configuration
    • setRpc

      public void setRpc(@NonNull @NonNull RabbitConnectionFactoryConfig.RpcConfiguration rpc)
      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

      public Optional<List<com.rabbitmq.client.Address>> getAddresses()
      Returns:
      An optional list of addresses
    • setAddresses

      public void setAddresses(@Nullable @Nullable List<com.rabbitmq.client.Address> addresses)
      Sets the addresses to be passed to ConnectionFactory.newConnection(List).
      Parameters:
      addresses - The list of addresses
    • getConsumerExecutor

      public String getConsumerExecutor()
      Returns:
      The executor service name that consumers should be executed on
    • setConsumerExecutor

      public void setConsumerExecutor(@NonNull @NonNull String consumerExecutor)
      Sets the name of which executor service consumers should be executed on. Default "consumer".
      Parameters:
      consumerExecutor - The consumer executor service name.
    • getConfirmTimeout

      public Duration getConfirmTimeout()
      Returns:
      How long to wait for a publisher confirm
    • setConfirmTimeout

      public void setConfirmTimeout(Duration confirmTimeout)
      Parameters:
      confirmTimeout - How long to wait for a publisher confirm. Default value (5s).