Class RabbitMQConnectorIncomingConfiguration
- java.lang.Object
-
- io.smallrye.reactive.messaging.rabbitmq.RabbitMQConnectorCommonConfiguration
-
- io.smallrye.reactive.messaging.rabbitmq.RabbitMQConnectorIncomingConfiguration
-
public class RabbitMQConnectorIncomingConfiguration extends RabbitMQConnectorCommonConfiguration
Extract the incoming configuration for thesmallrye-rabbitmqconnector.
-
-
Field Summary
-
Fields inherited from class io.smallrye.reactive.messaging.rabbitmq.RabbitMQConnectorCommonConfiguration
config
-
-
Constructor Summary
Constructors Constructor Description RabbitMQConnectorIncomingConfiguration(org.eclipse.microprofile.config.Config config)Creates a new RabbitMQConnectorIncomingConfiguration.
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description BooleangetAutoAcknowledgement()Gets the auto-acknowledgement value from the configuration.BooleangetAutoBindDlq()Gets the auto-bind-dlq value from the configuration.BooleangetBroadcast()Gets the broadcast value from the configuration.StringgetDeadLetterExchange()Gets the dead-letter-exchange value from the configuration.StringgetDeadLetterExchangeType()Gets the dead-letter-exchange-type value from the configuration.Optional<String>getDeadLetterQueueName()Gets the dead-letter-queue-name value from the configuration.Optional<String>getDeadLetterRoutingKey()Gets the dead-letter-routing-key value from the configuration.BooleangetDlxDeclare()Gets the dlx.declare value from the configuration.StringgetFailureStrategy()Gets the failure-strategy value from the configuration.BooleangetKeepMostRecent()Gets the keep-most-recent value from the configuration.Optional<Integer>getMaxIncomingInternalQueueSize()Gets the max-incoming-internal-queue-size value from the configuration.BooleangetQueueAutoDelete()Gets the queue.auto-delete value from the configuration.BooleangetQueueDeclare()Gets the queue.declare value from the configuration.BooleangetQueueDurable()Gets the queue.durable value from the configuration.BooleangetQueueExclusive()Gets the queue.exclusive value from the configuration.StringgetQueueName()Gets the queue.name value from the configuration.Optional<Long>getQueueTtl()Gets the queue.ttl value from the configuration.StringgetRoutingKeys()Gets the routing-keys value from the configuration.voidvalidate()-
Methods inherited from class io.smallrye.reactive.messaging.rabbitmq.RabbitMQConnectorCommonConfiguration
config, getAutomaticRecoveryEnabled, getAutomaticRecoveryOnInitialConnection, getChannel, getConnectionTimeout, getExchangeAutoDelete, getExchangeDeclare, getExchangeDurable, getExchangeName, getExchangeType, getFromAlias, getFromAliasWithDefaultValue, getHandshakeTimeout, getHost, getIncludeProperties, getNetworkRecoveryInterval, getPassword, getPort, getReconnectAttempts, getReconnectInterval, getRequestedChannelMax, getRequestedHeartbeat, getTracingAttributeHeaders, getTracingEnabled, getUseNio, getUser, getUsername, getVirtualHost
-
-
-
-
Method Detail
-
getQueueName
public String getQueueName()
Gets the queue.name value from the configuration. Attribute Name: queue.name Description: The queue from which messages are consumed. Mandatory: yes- Returns:
- the queue.name
-
getQueueDurable
public Boolean getQueueDurable()
Gets the queue.durable value from the configuration. Attribute Name: queue.durable Description: Whether the queue is durable Default Value: true- Returns:
- the queue.durable
-
getQueueExclusive
public Boolean getQueueExclusive()
Gets the queue.exclusive value from the configuration. Attribute Name: queue.exclusive Description: Whether the queue is for exclusive use Default Value: false- Returns:
- the queue.exclusive
-
getQueueAutoDelete
public Boolean getQueueAutoDelete()
Gets the queue.auto-delete value from the configuration. Attribute Name: queue.auto-delete Description: Whether the queue should be deleted after use Default Value: false- Returns:
- the queue.auto-delete
-
getQueueDeclare
public Boolean getQueueDeclare()
Gets the queue.declare value from the configuration. Attribute Name: queue.declare Description: Whether to declare the queue and binding; set to false if these are expected to be set up independently Default Value: true- Returns:
- the queue.declare
-
getQueueTtl
public Optional<Long> getQueueTtl()
Gets the queue.ttl value from the configuration. Attribute Name: queue.ttl Description: If specified, the time (ms) for which a message can remain in the queue undelivered before it is dead- Returns:
- the queue.ttl
-
getMaxIncomingInternalQueueSize
public Optional<Integer> getMaxIncomingInternalQueueSize()
Gets the max-incoming-internal-queue-size value from the configuration. Attribute Name: max-incoming-internal-queue-size Description: The maximum size of the incoming internal queue- Returns:
- the max-incoming-internal-queue-size
-
getAutoBindDlq
public Boolean getAutoBindDlq()
Gets the auto-bind-dlq value from the configuration. Attribute Name: auto-bind-dlq Description: Whether to automatically declare the DLQ and bind it to the binder DLX Default Value: false- Returns:
- the auto-bind-dlq
-
getDeadLetterQueueName
public Optional<String> getDeadLetterQueueName()
Gets the dead-letter-queue-name value from the configuration. Attribute Name: dead-letter-queue-name Description: The name of the DLQ; if not supplied will default to the queue name with '.dlq' appended- Returns:
- the dead-letter-queue-name
-
getDeadLetterExchange
public String getDeadLetterExchange()
Gets the dead-letter-exchange value from the configuration. Attribute Name: dead-letter-exchange Description: A DLX to assign to the queue. Relevant only if auto-bind-dlq is true Default Value: DLX- Returns:
- the dead-letter-exchange
-
getDeadLetterExchangeType
public String getDeadLetterExchangeType()
Gets the dead-letter-exchange-type value from the configuration. Attribute Name: dead-letter-exchange-type Description: The type of the DLX to assign to the queue. Relevant only if auto-bind-dlq is true Default Value: direct- Returns:
- the dead-letter-exchange-type
-
getDeadLetterRoutingKey
public Optional<String> getDeadLetterRoutingKey()
Gets the dead-letter-routing-key value from the configuration. Attribute Name: dead-letter-routing-key Description: A dead letter routing key to assign to the queue; if not supplied will default to the queue name- Returns:
- the dead-letter-routing-key
-
getDlxDeclare
public Boolean getDlxDeclare()
Gets the dlx.declare value from the configuration. Attribute Name: dlx.declare Description: Whether to declare the dead letter exchange binding. Relevant only if auto-bind-dlq is true; set to false if these are expected to be set up independently Default Value: false- Returns:
- the dlx.declare
-
getFailureStrategy
public String getFailureStrategy()
Gets the failure-strategy value from the configuration. Attribute Name: failure-strategy Description: The failure strategy to apply when a RabbitMQ message is nacked. Accepted values are `fail`, `accept`, `reject` (default) Default Value: reject- Returns:
- the failure-strategy
-
getBroadcast
public Boolean getBroadcast()
Gets the broadcast value from the configuration. Attribute Name: broadcast Description: Whether the received RabbitMQ messages must be dispatched to multiple _subscribers_ Default Value: false- Returns:
- the broadcast
-
getAutoAcknowledgement
public Boolean getAutoAcknowledgement()
Gets the auto-acknowledgement value from the configuration. Attribute Name: auto-acknowledgement Description: Whether the received RabbitMQ messages must be acknowledged when received; if true then delivery constitutes acknowledgement Default Value: false- Returns:
- the auto-acknowledgement
-
getKeepMostRecent
public Boolean getKeepMostRecent()
Gets the keep-most-recent value from the configuration. Attribute Name: keep-most-recent Description: Whether to discard old messages instead of recent ones Default Value: false- Returns:
- the keep-most-recent
-
getRoutingKeys
public String getRoutingKeys()
Gets the routing-keys value from the configuration. Attribute Name: routing-keys Description: A comma-separated list of routing keys to bind the queue to the exchange Default Value: #- Returns:
- the routing-keys
-
validate
public void validate()
- Overrides:
validatein classRabbitMQConnectorCommonConfiguration
-
-