Class RabbitMQPublisherOptions


  • public class RabbitMQPublisherOptions
    extends Object
    RabbitMQ client options, most
    Author:
    Julien Viet
    • Field Detail

      • DEFAULT_RECONNECT_INTERVAL

        public static final long DEFAULT_RECONNECT_INTERVAL
        The default connection retry delay = 10000
        See Also:
        Constant Field Values
      • DEFAULT_RECONNECT_ATTEMPTS

        public static final Integer DEFAULT_RECONNECT_ATTEMPTS
        The default connection retries = Integer.MAX_VALUE
    • Constructor Detail

      • RabbitMQPublisherOptions

        public RabbitMQPublisherOptions()
      • RabbitMQPublisherOptions

        public RabbitMQPublisherOptions​(JsonObject json)
    • Method Detail

      • getReconnectAttempts

        public Integer getReconnectAttempts()
        Returns:
        the number of reconnect attempts
      • setReconnectAttempts

        public RabbitMQPublisherOptions setReconnectAttempts​(Integer reconnectAttempts)
        Set the number of reconnect attempts to attempt when connecting, the null value disables it.
        Parameters:
        reconnectAttempts - the number of retries
        Returns:
        a reference to this, so the API can be used fluently
      • getReconnectInterval

        public long getReconnectInterval()
        Returns:
        the delay in milliseconds between connection retries
      • setReconnectInterval

        public RabbitMQPublisherOptions setReconnectInterval​(long reconnectInterval)
        Set the delay in milliseconds between connection retries.
        Parameters:
        reconnectInterval - the delay in milliseconds
        Returns:
        a reference to this, so the API can be used fluently
      • getMaxInternalQueueSize

        public int getMaxInternalQueueSize()
        Returns:
        the size of internal queue
      • setMaxInternalQueueSize

        public RabbitMQPublisherOptions setMaxInternalQueueSize​(int maxInternalQueueSize)
        Parameters:
        maxInternalQueueSize - the size of internal queue
        Returns:
        a reference to this, so the API can be used fluently