Root Element

ElementDescriptionClass
brokerAn ActiveMQ Message Broker. It consists of a number of transport connectors, network connectors and a bunch of properties which can be used to configure the broker as its lazily created.org.apache.activemq.xbean.XBeanBrokerService

Element Summary

ElementDescriptionClass
abortSlowAckConsumerStrategyAbort slow consumers when they reach the configured threshold of slowness, default is that a consumer that has not Ack'd a message for 30 seconds is slow.org.apache.activemq.broker.region.policy.AbortSlowAckConsumerStrategy
abortSlowConsumerStrategyAbort slow consumers when they reach the configured threshold of slowness, default is slow for 30 secondsorg.apache.activemq.broker.region.policy.AbortSlowConsumerStrategy
authenticationUserA helper object used to configure simple authentiaction pluginorg.apache.activemq.security.AuthenticationUser
authorizationEntryRepresents an entry in a {@link DefaultAuthorizationMap} for assigning different operations (read, write, admin) of user roles to a specific destination or a hierarchical wildcard area of destinations.org.apache.activemq.security.XBeanAuthorizationEntry
authorizationMaporg.apache.activemq.security.XBeanAuthorizationMap
authorizationPluginAn authorization plugin where each operation on a destination is checked against an authorizationMaporg.apache.activemq.security.AuthorizationPlugin
axionJDBCAdapterAxion specific Adapter. Axion does not seem to support ALTER statements or sub-selects. This means: - We cannot auto upgrade the schema was we roll out new versions of ActiveMQ - We cannot delete durable sub messages that have be acknowledged by all consumers.org.apache.activemq.store.jdbc.adapter.AxionJDBCAdapter
blobJDBCAdapterThis JDBCAdapter inserts and extracts BLOB data using the getBlob()/setBlob() operations. This is a little more involved since to insert a blob you have to: 1: insert empty blob. 2: select the blob 3: finally update the blob with data value. The databases/JDBC drivers that use this adapter are:
org.apache.activemq.store.jdbc.adapter.BlobJDBCAdapter
brokerAn ActiveMQ Message Broker. It consists of a number of transport connectors, network connectors and a bunch of properties which can be used to configure the broker as its lazily created.org.apache.activemq.xbean.XBeanBrokerService
brokerServiceManages the life-cycle of an ActiveMQ Broker. A BrokerService consists of a number of transport connectors, network connectors and a bunch of properties which can be used to configure the broker as its lazily created.org.apache.activemq.broker.BrokerService
bytesJDBCAdapterThis JDBCAdapter inserts and extracts BLOB data using the setBytes()/getBytes() operations. The databases/JDBC drivers that use this adapter are:org.apache.activemq.store.jdbc.adapter.BytesJDBCAdapter
cachedLDAPAuthorizationMapA {@link DefaultAuthorizationMap} implementation which uses LDAP to initialize and update authorization policy.org.apache.activemq.security.CachedLDAPAuthorizationMap
cachedMessageGroupMapFactoryA factory to create instances of {@link org.apache.activemq.broker.region.group.CachedMessageGroupMap} when implementing the Message Groups functionality.org.apache.activemq.broker.region.group.CachedMessageGroupMapFactory
compositeDemandForwardingBridgeA demand forwarding bridge which works with multicast style transports where a single Transport could be communicating with multiple remote brokersorg.apache.activemq.network.CompositeDemandForwardingBridge
compositeQueueRepresents a virtual queue which forwards to a number of other destinations.org.apache.activemq.broker.region.virtual.CompositeQueue
compositeTopicRepresents a virtual topic which forwards to a number of other destinations.org.apache.activemq.broker.region.virtual.CompositeTopic
conditionalNetworkBridgeFilterFactoryimplement conditional behavior for queue consumers, allows replaying back to origin if no consumers are present on the local broker after a configurable delay, irrespective of the TTL. Also allows rate limiting of messages through the network, useful for static includesorg.apache.activemq.network.ConditionalNetworkBridgeFilterFactory
connectionDotFilePluginA DOT file creator plugin which creates a DOT file showing the current connectionsorg.apache.activemq.broker.view.ConnectionDotFilePlugin
connectionFactoryA Spring enhanced connection factory which will automatically use the Spring bean name as the clientIDPrefix property so that connections created have client IDs related to your Spring.xml file for easier comprehension from JMX.org.apache.activemq.spring.ActiveMQConnectionFactory
constantPendingMessageLimitStrategyThis PendingMessageLimitStrategy is configured to a constant value for all subscriptions.org.apache.activemq.broker.region.policy.ConstantPendingMessageLimitStrategy
database-lockerRepresents an exclusive lock on a database to avoid multiple brokers running against the same logical database.org.apache.activemq.store.jdbc.DefaultDatabaseLocker
db2JDBCAdapterorg.apache.activemq.store.jdbc.adapter.DB2JDBCAdapter
defaultIOExceptionHandlerorg.apache.activemq.util.DefaultIOExceptionHandler
defaultJDBCAdapterImplements all the default JDBC operations that are used by the JDBCPersistenceAdapter.

sub-classing is encouraged to override the default implementation of methods to account for differences in JDBC Driver implementations.

The JDBCAdapter inserts and extracts BLOB data using the getBytes()/setBytes() operations.

The databases/JDBC drivers that use this adapter are:

org.apache.activemq.store.jdbc.adapter.DefaultJDBCAdapter
defaultNetworkBridgeFilterFactoryimplement default behavior, filter that will not allow re-send to origin based on brokerPath and which respects networkTTLorg.apache.activemq.network.DefaultNetworkBridgeFilterFactory
defaultUsageCapacityIdentify if a limit has been reachedorg.apache.activemq.usage.DefaultUsageCapacity
demandForwardingBridgeForwards messages from the local broker to the remote broker based on demand.org.apache.activemq.network.DemandForwardingBridge
destinationDotFilePluginA DOT file creator plugin which creates a DOT file showing the current topic & queue hierarchies.org.apache.activemq.broker.view.DestinationDotFilePlugin
destinationEntryA default entry in a DestinationMap which holds a single value.org.apache.activemq.filter.DefaultDestinationMapEntry
destinationPathSeparatorPluginorg.apache.activemq.broker.util.DestinationPathSeparatorBroker
discardingDead Letter Strategy that discards all messagesorg.apache.activemq.broker.region.policy.DiscardingDeadLetterStrategy
discardingDLQBrokerPluginorg.apache.activemq.plugin.DiscardingDLQBrokerPlugin
fileCursorPending messagesorg.apache.activemq.broker.region.policy.FilePendingSubscriberMessageStoragePolicy
fileDurableSubscriberCursorPending messages for durable subscribersorg.apache.activemq.broker.region.policy.FilePendingDurableSubscriberMessageStoragePolicy
fileQueueCursorPendingorg.apache.activemq.broker.region.policy.FilePendingQueueMessageStoragePolicy
filteredDestinationRepresents a destination which is filtered using some predicate such as a selector so that messages are only dispatched to the destination if they match the filter.org.apache.activemq.broker.region.virtual.FilteredDestination
filteredKahaDBorg.apache.activemq.store.kahadb.FilteredKahaDBPersistenceAdapter
fixedCountSubscriptionRecoveryPolicyThis implementation of {@link SubscriptionRecoveryPolicy} will keep a fixed count of last messages.org.apache.activemq.broker.region.policy.FixedCountSubscriptionRecoveryPolicy
fixedSizedSubscriptionRecoveryPolicyThis implementation of {@link SubscriptionRecoveryPolicy} will keep a fixed amount of memory available in RAM for message history which is evicted in time order.org.apache.activemq.broker.region.policy.FixedSizedSubscriptionRecoveryPolicy
forcePersistencyModeBrokerA Plugin which allows to force every incoming message to be PERSISTENT or NON-PERSISTENT. Useful, if you have set the broker usage policy to process ONLY persistent or ONLY non-persistent messages.org.apache.activemq.plugin.ForcePersistencyModeBroker
forcePersistencyModeBrokerPluginA Plugin which allows to force every incoming message to be PERSISTENT or NON-PERSISTENT. Useful, if you have set the broker usage policy to process ONLY persistent or ONLY non-persistent messages.org.apache.activemq.plugin.ForcePersistencyModeBrokerPlugin
forwardingBridgeForwards all messages from the local broker to the remote broker.org.apache.activemq.network.ForwardingBridge
hsqldb-jdbc-adapterorg.apache.activemq.store.jdbc.adapter.HsqldbJDBCAdapter
imageBasedJDBCAdaptorProvides JDBCAdapter since that uses IMAGE datatype to hold binary data. The databases/JDBC drivers that use this adapter are:
  • Sybase
  • MS SQL
org.apache.activemq.store.jdbc.adapter.ImageBasedJDBCAdaptor
inboundQueueBridgeCreate an Inbound Queue Bridge. By default this class uses the sname name for both the inbound and outbound queue. This behavior can be overridden however by using the setter methods to configure both the inbound and outboud queue names separately.org.apache.activemq.network.jms.InboundQueueBridge
inboundTopicBridgeCreate an Inbound Topic Bridge. By default this class uses the topic name for both the inbound and outbound topic. This behavior can be overridden however by using the setter methods to configure both the inbound and outboud topic names separately.org.apache.activemq.network.jms.InboundTopicBridge
individualDeadLetterStrategyA {@link DeadLetterStrategy} where each destination has its own individual DLQ using the subject naming hierarchy.org.apache.activemq.broker.region.policy.IndividualDeadLetterStrategy
informixJDBCAdapterJDBC Adapter for Informix database. Because Informix database restricts length of composite primary keys, length of container name field and subscription id field must be reduced to 150 characters. Therefore be sure not to use longer names for container name and subscription id than 150 characters.org.apache.activemq.store.jdbc.adapter.InformixJDBCAdapter
jDBCIOExceptionHandlerorg.apache.activemq.store.jdbc.JDBCIOExceptionHandler
jaasAuthenticationPluginProvides a JAAS based authentication pluginorg.apache.activemq.security.JaasAuthenticationPlugin
jaasCertificateAuthenticationPluginProvides a JAAS based SSL certificate authentication pluginorg.apache.activemq.security.JaasCertificateAuthenticationPlugin
jaasDualAuthenticationPluginProvides a JAAS based authentication pluginorg.apache.activemq.security.JaasDualAuthenticationPlugin
jdbcPersistenceAdapterA {@link PersistenceAdapter} implementation using JDBC for persistence storage. This persistence adapter will correctly remember prepared XA transactions, but it will not keep track of local transaction commits so that operations performed against the Message store are done as a single uow.org.apache.activemq.store.jdbc.JDBCPersistenceAdapter
jmsQueueConnectorA Bridge to other JMS Queue providersorg.apache.activemq.network.jms.JmsQueueConnector
jmsTopicConnectorA Bridge to other JMS Topic providersorg.apache.activemq.network.jms.JmsTopicConnector
jobSchedulerUsageUsed to keep track of how much of something is being used so that a productive working set usage can be controlled. Main use case is manage memory usage.org.apache.activemq.usage.JobSchedulerUsage
journalPersistenceAdapterAn implementation of {@link PersistenceAdapter} designed for use with a {@link Journal} and then check pointing asynchronously on a timeout with some other long term persistent storage.org.apache.activemq.store.journal.JournalPersistenceAdapter
journalPersistenceAdapterFactoryFactory class that can create PersistenceAdapter objects.org.apache.activemq.store.journal.JournalPersistenceAdapterFactory
journaledJDBCCreates a default persistence model using the Journal and JDBCorg.apache.activemq.store.PersistenceAdapterFactoryBean
kahaDBAn implementation of {@link PersistenceAdapter} designed for use with KahaDB - Embedded Lightweight Non-Relational Databaseorg.apache.activemq.store.kahadb.KahaDBPersistenceAdapter
lDAPAuthorizationMapAn {@link AuthorizationMap} which uses LDAPorg.apache.activemq.security.LDAPAuthorizationMap
lastImageSubscriptionRecoveryPolicyThis implementation of {@link SubscriptionRecoveryPolicy} will only keep the last message.org.apache.activemq.broker.region.policy.LastImageSubscriptionRecoveryPolicy
ldapNetworkConnectorclass to create dynamic network connectors listed in an directory server using the LDAP v3 protocol as defined in RFC 2251, the entries listed in the directory server must implement the ipHost and ipService objectClasses as defined in RFC 2307.org.apache.activemq.network.LdapNetworkConnector
lease-database-lockerRepresents an exclusive lease on a database to avoid multiple brokers running against the same logical database.org.apache.activemq.store.jdbc.LeaseDatabaseLocker
levelDBAn implementation of {@link org.apache.activemq.store.PersistenceAdapter} designed for use with LevelDB - Embedded Lightweight Non-Relational Databaseorg.apache.activemq.store.leveldb.LevelDBPersistenceAdapter
loggingBrokerPluginA simple Broker intercepter which allows you to enable/disable logging.org.apache.activemq.broker.util.LoggingBrokerPlugin
mKahaDBAn implementation of {@link org.apache.activemq.store.PersistenceAdapter} that supports distribution of destinations across multiple kahaDB persistence adaptersorg.apache.activemq.store.kahadb.MultiKahaDBPersistenceAdapter
managementContextAn abstraction over JMX mbean registrationorg.apache.activemq.broker.jmx.ManagementContext
maxdb-jdbc-adapterJDBC Adapter for the MaxDB database.org.apache.activemq.store.jdbc.adapter.MaxDBJDBCAdapter
memoryPersistenceAdapterorg.apache.activemq.store.memory.MemoryPersistenceAdapter
memoryUsageUsed to keep track of how much of something is being used so that a productive working set usage can be controlled. Main use case is manage memory usage.org.apache.activemq.usage.MemoryUsage
messageGroupHashBucketFactoryA factory to create instances of {@link SimpleMessageGroupMap} when implementing the Message Groups functionality.org.apache.activemq.broker.region.group.MessageGroupHashBucketFactory
mirroredQueueCreates Mirrored Queue using a prefix and postfix to define the topic name on which to mirror the queue to.org.apache.activemq.broker.region.virtual.MirroredQueue
multicastNetworkConnectorA network connector which uses some kind of multicast-like transport that communicates with potentially many remote brokers over a single logical {@link Transport} instance such as when using multicast. This implementation does not depend on multicast at all; any other group based transport could be used.org.apache.activemq.network.MulticastNetworkConnector
multicastTraceBrokerPluginA Broker interceptor which allows you to trace all operations to a Multicast socket.org.apache.activemq.broker.util.MulticastTraceBrokerPlugin
mysql-jdbc-adapterorg.apache.activemq.store.jdbc.adapter.MySqlJDBCAdapter
networkConnectorA network connector which uses a discovery agent to detect the remote brokers available and setup a connection to each available remote brokerorg.apache.activemq.network.DiscoveryNetworkConnector
noSubscriptionRecoveryPolicyThis SubscriptionRecoveryPolicy disable recovery of messages.org.apache.activemq.broker.region.policy.NoSubscriptionRecoveryPolicy
oldestMessageEvictionStrategyAn eviction strategy which evicts the oldest message first (which is the default).org.apache.activemq.broker.region.policy.OldestMessageEvictionStrategy
oldestMessageWithLowestPriorityEvictionStrategyAn eviction strategy which evicts the oldest message with the lowest priority first.org.apache.activemq.broker.region.policy.OldestMessageWithLowestPriorityEvictionStrategy
oracleBlobJDBCAdapterImplements all the default JDBC operations that are used by the JDBCPersistenceAdapter.

Subclassing is encouraged to override the default implementation of methods to account for differences in JDBC Driver implementations.

The JDBCAdapter inserts and extracts BLOB data using the getBytes()/setBytes() operations.

The databases/JDBC drivers that use this adapter are:

org.apache.activemq.store.jdbc.adapter.OracleBlobJDBCAdapter
oracleJDBCAdapterImplements all the default JDBC operations that are used by the JDBCPersistenceAdapter.

Subclassing is encouraged to override the default implementation of methods to account for differences in JDBC Driver implementations.

org.apache.activemq.store.jdbc.adapter.OracleJDBCAdapter
outboundQueueBridgeCreate an Outbound Queue Bridge. By default the bridge uses the same name for both the inbound and outbound queues, however this can be altered by using the public setter methods to configure both inbound and outbound queue names.org.apache.activemq.network.jms.OutboundQueueBridge
outboundTopicBridgeCreate an Outbound Topic Bridge. By default the bridge uses the same name for both the inbound and outbound topics, however this can be altered by using the public setter methods to configure both inbound and outbound topic names.org.apache.activemq.network.jms.OutboundTopicBridge
pListStoreImplorg.apache.activemq.store.kahadb.plist.PListStoreImpl
partitionBrokerPluginA BrokerPlugin which partitions client connections over a cluster of brokers.org.apache.activemq.partition.PartitionBrokerPlugin
policyEntryRepresents an entry in a {@link PolicyMap} for assigning policies to a specific destination or a hierarchical wildcard area of destinations.org.apache.activemq.broker.region.policy.PolicyEntry
policyMapRepresents a destination based configuration of policies so that individual destinations or wildcard hierarchies of destinations can be configured using different policies.org.apache.activemq.broker.region.policy.PolicyMap
pooledConnectionFactorySimple factory bean used to create a jencks connection pool. Depending on the properties set, it will create a simple pool, a transaction aware connection pool, or a jca aware connection pool.

  
  
  

The resourceName property should be used along with the {@link org.apache.activemq.jms.pool.GenericResourceManager} and have the same value than its resourceName property. This will make sure the transaction manager maps correctly the connection factory to the recovery process.
org.apache.activemq.pool.PooledConnectionFactoryBean
postgresql-jdbc-adapterImplements all the default JDBC operations that are used by the JDBCPersistenceAdapter.

Subclassing is encouraged to override the default implementation of methods to account for differences in JDBC Driver implementations.

The JDBCAdapter inserts and extracts BLOB data using the getBytes()/setBytes() operations.

The databases/JDBC drivers that use this adapter are:

org.apache.activemq.store.jdbc.adapter.PostgresqlJDBCAdapter
prefetchPolicyDefines the prefetch message policies for different types of consumersorg.apache.activemq.ActiveMQPrefetchPolicy
prefetchRatePendingMessageLimitStrategyThis PendingMessageLimitStrategy sets the maximum pending message limit value to be a multiplier of the prefetch limit of the subscription.org.apache.activemq.broker.region.policy.PrefetchRatePendingMessageLimitStrategy
priorityDispatchPolicyPriority dispatch policy that sends a message to every subscription that matches the message in consumer priority order.org.apache.activemq.broker.region.policy.PriorityDispatchPolicy
priorityNetworkDispatchPolicydispatch policy that ignores lower priority duplicate network consumers, used in conjunction with network bridge suppresDuplicateTopicSubscriptionsorg.apache.activemq.broker.region.policy.PriorityNetworkDispatchPolicy
proxyConnectororg.apache.activemq.proxy.ProxyConnector
publishedAddressPolicyPolicy object that controls how a TransportConnector publishes the connector's address to the outside world. By default the connector will publish itself using the resolved host name of the bound server socket.org.apache.activemq.broker.PublishedAddressPolicy
queryBasedSubscriptionRecoveryPolicyThis implementation of {@link SubscriptionRecoveryPolicy} will perform a user specific query mechanism to load any messages they may have missed.org.apache.activemq.broker.region.policy.QueryBasedSubscriptionRecoveryPolicy
queueAn ActiveMQ Queueorg.apache.activemq.command.ActiveMQQueue
queueDispatchSelectorQueue dispatch policy that determines if a message can be sent to a subscriptionorg.apache.activemq.broker.region.QueueDispatchSelector
reconnectionPolicyA policy object that defines how a {@link JmsConnector} deals with reconnection of the local and foreign connections.org.apache.activemq.network.jms.ReconnectionPolicy
redeliveryPluginReplace regular DLQ handling with redelivery via a resend to the original destination after a delay A destination matching RedeliveryPolicy controls the quantity and delay for re-sends If there is no matching policy or an existing policy limit is exceeded by default regular DLQ processing resumes. This is controlled via sendToDlqIfMaxRetriesExceeded and fallbackToDeadLetterorg.apache.activemq.broker.util.RedeliveryPlugin
redeliveryPolicyConfiguration options for a messageConsumer used to control how messages are re-delivered when they are rolled back. May be used server side on a per destination basis via the Broker RedeliveryPluginorg.apache.activemq.RedeliveryPolicy
redeliveryPolicyMapRepresents a destination based configuration of policies so that individual destinations or wildcard hierarchies of destinations can be configured using different policies.org.apache.activemq.broker.region.policy.RedeliveryPolicyMap
replicatedLevelDBAn implementation of {@link org.apache.activemq.store.PersistenceAdapter} designed for use with LevelDB - Embedded Lightweight Non-Relational Databaseorg.apache.activemq.store.leveldb.ReplicatedLevelDBPersistenceAdapter
roundRobinDispatchPolicySimple dispatch policy that sends a message to every subscription that matches the message.org.apache.activemq.broker.region.policy.RoundRobinDispatchPolicy
runtimeConfigurationPluginBroker plugin that will monitor the broker xml configuration for changes and selectively apply those changes to the running broker.org.apache.activemq.plugin.RuntimeConfigurationPlugin
shared-file-lockerRepresents an exclusive lock on a database to avoid multiple brokers running against the same logical database.org.apache.activemq.store.SharedFileLocker
sharedDeadLetterStrategyA default implementation of {@link DeadLetterStrategy} which uses a constant destination.org.apache.activemq.broker.region.policy.SharedDeadLetterStrategy
simpleAuthenticationPluginProvides a simple authentication pluginorg.apache.activemq.security.SimpleAuthenticationPlugin
simpleAuthorizationMapAn AuthorizationMap which is configured with individual DestinationMaps for each operation.org.apache.activemq.security.SimpleAuthorizationMap
simpleDispatchPolicySimple dispatch policy that sends a message to every subscription that matches the message.org.apache.activemq.broker.region.policy.SimpleDispatchPolicy
simpleDispatchSelectorSimple dispatch policy that determines if a message can be sent to a subscriptionorg.apache.activemq.broker.region.policy.SimpleDispatchSelector
simpleJmsMessageConvertorConverts Message from one JMS to anotherorg.apache.activemq.network.jms.SimpleJmsMessageConvertor
simpleMessageGroupMapFactoryA factory to create instances of {@link SimpleMessageGroupMap} when implementing the Message Groups functionality.org.apache.activemq.broker.region.group.SimpleMessageGroupMapFactory
sslContextExtends the SslContext so that it's easier to configure from spring.org.apache.activemq.spring.SpringSslContext
statementsorg.apache.activemq.store.jdbc.Statements
statisticsBrokerPluginA StatisticsBrokerPlugin You can retrieve a Map Message for a Destination - or Broker containing statistics as key-value pairs The message must contain a replyTo Destination - else its ignored To retrieve stats on the broker send a empty message to ActiveMQ.Statistics.Broker (Queue or Topic) With a replyTo set to the destination you want the stats returned to. To retrieve stats for a destination - e.g. foo - send an empty message to ActiveMQ.Statistics.Destination.foo - this works with wildcards to - you get a message for each wildcard match on the replyTo destination. The stats message is a MapMessage populated with statistics for the targetorg.apache.activemq.plugin.StatisticsBrokerPlugin
storeCursorPending messagesorg.apache.activemq.broker.region.policy.StorePendingQueueMessageStoragePolicy
storeDurableSubscriberCursorPending messages for a durableorg.apache.activemq.broker.region.policy.StorePendingDurableSubscriberMessageStoragePolicy
storeUsageUsed to keep track of how much of something is being used so that a productive working set usage can be controlled. Main use case is manage memory usage.org.apache.activemq.usage.StoreUsage
streamJDBCAdapterThis JDBCAdapter inserts and extracts BLOB data using the setBinaryStream()/getBinaryStream() operations. The databases/JDBC drivers that use this adapter are:
  • Axion
org.apache.activemq.store.jdbc.adapter.StreamJDBCAdapter
strictOrderDispatchPolicyDispatch policy that causes every subscription to see messages in the same order.org.apache.activemq.broker.region.policy.StrictOrderDispatchPolicy
sybase-jdbc-adapterA JDBC Adapter for Sybase databasesorg.apache.activemq.store.jdbc.adapter.SybaseJDBCAdapter
systemUsageHolder for Usage instances for memory, store and temp files Main use case is manage memory usage.org.apache.activemq.usage.SystemUsage
taskRunnerFactoryManages the thread pool for long running tasks. Long running tasks are not always active but when they are active, they may need a few iterations of processing for them to become idle. The manager ensures that each task is processes but that no one task overtakes the system. This is kinda like cooperative multitasking.org.apache.activemq.thread.TaskRunnerFactory
tempDestinationAuthorizationEntryRepresents an entry in a {@link DefaultAuthorizationMap} for assigning different operations (read, write, admin) of user roles to a temporary destinationorg.apache.activemq.security.TempDestinationAuthorizationEntry
tempQueueAn ActiveMQ Temporary Queue Destinationorg.apache.activemq.command.ActiveMQTempQueue
tempTopicAn ActiveMQ Temporary Topic Destinationorg.apache.activemq.command.ActiveMQTempTopic
tempUsageUsed to keep track of how much of something is being used so that a productive working set usage can be controlled. Main use case is manage memory usage.org.apache.activemq.usage.TempUsage
timeStampingBrokerPluginA Broker interceptor which updates a JMS Client's timestamp on the message with a broker timestamp. Useful when the clocks on client machines are known to not be correct and you can only trust the time set on the broker machines. Enabling this plugin will break JMS compliance since the timestamp that the producer sees on the messages after as send() will be different from the timestamp the consumer will observe when he receives the message. This plugin is not enabled in the default ActiveMQ configuration. 2 new attributes have been added which will allow the administrator some override control over the expiration time for incoming messages: Attribute 'zeroExpirationOverride' can be used to apply an expiration time to incoming messages with no expiration defined (messages that would never expire) Attribute 'ttlCeiling' can be used to apply a limit to the expiration timeorg.apache.activemq.broker.util.TimeStampingBrokerPlugin
timedSubscriptionRecoveryPolicyThis implementation of {@link SubscriptionRecoveryPolicy} will keep a timed buffer of messages around in memory and use that to recover new subscriptions.org.apache.activemq.broker.region.policy.TimedSubscriptionRecoveryPolicy
topicAn ActiveMQ Topicorg.apache.activemq.command.ActiveMQTopic
traceBrokerPathPluginThe TraceBrokerPathPlugin can be used in a network of Brokers. Each Broker that has the plugin configured, will add it's brokerName to the content of a JMS Property. If all Brokers have this property enabled, the path the message actually took through the network can be seen in the defined property.org.apache.activemq.broker.util.TraceBrokerPathPlugin
transact-database-lockerRepresents an exclusive lock on a database to avoid multiple brokers running against the same logical database.org.apache.activemq.store.jdbc.adapter.TransactDatabaseLocker
transact-jdbc-adapterA JDBC Adapter for Transact-SQL based databases such as SQL Server or Sybaseorg.apache.activemq.store.jdbc.adapter.TransactJDBCAdapter
transportConnectororg.apache.activemq.broker.TransportConnector
udpTraceBrokerPluginA Broker interceptor which allows you to trace all operations to a UDP socket.org.apache.activemq.broker.util.UDPTraceBrokerPlugin
uniquePropertyMessageEvictionStrategyAn eviction strategy which evicts the oldest message within messages with the same property valueorg.apache.activemq.broker.region.policy.UniquePropertyMessageEvictionStrategy
usageCapacityIdentify if a limit has been reachedorg.apache.activemq.usage.UsageCapacity
virtualDestinationInterceptorImplements Virtual Topics.org.apache.activemq.broker.region.virtual.VirtualDestinationInterceptor
virtualSelectorCacheBrokerPluginA plugin which allows the caching of the selector from a subscription queue.

This stops the build-up of unwanted messages, especially when consumers may disconnect from time to time when using virtual destinations.

This is influenced by code snippets developed by Maciej Rakowicz

org.apache.activemq.plugin.SubQueueSelectorCacheBrokerPlugin
virtualTopicCreates Virtual Topics using a prefix and postfix. The virtual destination creates a wildcard that is then used to look up all active queue subscriptions which match.org.apache.activemq.broker.region.virtual.VirtualTopic
vmCursorPending messages heldorg.apache.activemq.broker.region.policy.VMPendingSubscriberMessageStoragePolicy
vmDurableCursorPendingorg.apache.activemq.broker.region.policy.VMPendingDurableSubscriberMessageStoragePolicy
vmQueueCursorPending messagesorg.apache.activemq.broker.region.policy.VMPendingQueueMessageStoragePolicy
xaConnectionFactoryA Spring enhanced XA connection factory which will automatically use the Spring bean name as the clientIDPrefix property so that connections created have client IDs related to your Spring.xml file for easier comprehension from JMX.org.apache.activemq.spring.ActiveMQXAConnectionFactory

Element Detail

Element: abortSlowAckConsumerStrategy

AttributeTypeDescription
abortConnectionxs:booleanabort the consumers connection rather than sending a stop command to the remote consumer
checkPeriodxs:longtime in milliseconds between checks for slow subscriptions
ignoreIdleConsumersxs:booleanReturns whether the strategy is configured to ignore consumers that are simply idle, i.e consumers that have no pending acks (dispatch queue is empty).
ignoreNetworkConsumersxs:booleanSets whether the strategy is configured to ignore consumers that are part of a network connection to another broker. When configured to not ignore idle consumers this strategy acts not only on consumers that are actually slow but also on any consumer that has not received any messages for the maxTimeSinceLastAck. This allows for a way to evict idle consumers while also aborting slow consumers however for a network subscription this can create a lot of unnecessary churn and if the abort connection option is also enabled this can result in the entire network connection being torn down and rebuilt for no reason.
maxSlowCountxs:longnumber of times a subscription can be deemed slow before triggering abort effect depends on dispatch rate as slow determination is done on dispatch
maxSlowDurationxs:longtime in milliseconds that a sub can remain slow before triggering an abort.
maxTimeSinceLastAckxs:longGets the maximum time since last Ack before a subscription is considered to be slow.
namexs:string
ElementTypeDescription
brokerServicedestinationPathSeparatorPlugin | forcePersistencyModeBroker | loggingBrokerPlugin | multicastTraceBrokerPlugin | redeliveryPlugin | timeStampingBrokerPlugin | traceBrokerPathPlugin | udpTraceBrokerPlugin

Element: abortSlowConsumerStrategy

AttributeTypeDescription
abortConnectionxs:booleanabort the consumers connection rather than sending a stop command to the remote consumer
checkPeriodxs:longtime in milliseconds between checks for slow subscriptions
maxSlowCountxs:longnumber of times a subscription can be deemed slow before triggering abort effect depends on dispatch rate as slow determination is done on dispatch
maxSlowDurationxs:longtime in milliseconds that a sub can remain slow before triggering an abort.
namexs:string
ElementTypeDescription
brokerServicedestinationPathSeparatorPlugin | forcePersistencyModeBroker | loggingBrokerPlugin | multicastTraceBrokerPlugin | redeliveryPlugin | timeStampingBrokerPlugin | traceBrokerPathPlugin | udpTraceBrokerPlugin

Element: authenticationUser

AttributeTypeDescription
groupsxs:string
passwordxs:string
usernamexs:string

Element: authorizationEntry

AttributeTypeDescription
adminxs:string
groupClassxs:string
queuexs:stringA helper method to set the destination from a configuration file
readxs:string
tempQueuexs:boolean
tempTopicxs:boolean
topicxs:stringA helper method to set the destination from a configuration file
writexs:string
ElementTypeDescription
adminACLs(<spring:bean/>)*
destinationqueue | tempQueue | tempTopic | topic
readACLs(<spring:bean/>)*
writeACLs(<spring:bean/>)*

Element: authorizationMap

AttributeTypeDescription
groupClassxs:string
ElementTypeDescription
authorizationEntries(<spring:bean/>)*Sets the individual entries on the authorization map
defaultEntryauthorizationEntry | tempDestinationAuthorizationEntry
entries(<spring:bean/>)*A helper method to allow the destination map to be populated from a dependency injection framework such as Spring
tempDestinationAuthorizationEntrytempDestinationAuthorizationEntry

Element: authorizationPlugin

ElementTypeDescription
mapauthorizationMap | cachedLDAPAuthorizationMap | lDAPAuthorizationMap | simpleAuthorizationMap

Element: axionJDBCAdapter

AttributeTypeDescription
batchStatmentsxs:boolean
maxRowsxs:integerthe max value for statement maxRows, used to limit jdbc queries
useExternalMessageReferencesxs:boolean
ElementTypeDescription
statementsstatements

Element: blobJDBCAdapter

AttributeTypeDescription
batchStatmentsxs:boolean
maxRowsxs:integerthe max value for statement maxRows, used to limit jdbc queries
useExternalMessageReferencesxs:boolean
ElementTypeDescription
statementsstatements

Element: broker

AttributeTypeDescription
advisorySupportxs:stringAllows the support of advisory messages to be disabled for performance reasons.
allowTempAutoCreationOnSendxs:booleanenable if temp destinations need to be propagated through a network when advisorySupport==false. This is used in conjunction with the policy gcInactiveDestinations for matching temps so they can get removed when inactive
brokerIdxs:string
brokerNamexs:stringSets the name of this broker; which must be unique in the network
brokerObjectNamexs:stringSets the JMX ObjectName for this broker
cacheTempDestinationsxs:boolean
consumerSystemUsagePortionxs:integer
dataDirectoryxs:stringSets the directory in which the data files will be stored by default for the JDBC and Journal persistence adaptors.
dataDirectoryFilexs:stringSets the directory in which the data files will be stored by default for the JDBC and Journal persistence adaptors.
dedicatedTaskRunnerxs:boolean
deleteAllMessagesOnStartupxs:stringSets whether or not all messages are deleted on startup - mostly only useful for testing.
enableStatisticsxs:booleanSets whether or not the Broker's services enable statistics or not.
keepDurableSubsActivexs:boolean
maxPurgedDestinationsPerSweepxs:integer
mbeanInvocationTimeoutxs:longGets the time in Milliseconds that an invocation of an MBean method will wait before failing. The default value is to wait forever (zero).
monitorConnectionSplitsxs:boolean
networkConnectorStartAsyncxs:boolean
offlineDurableSubscriberTaskSchedulexs:long
offlineDurableSubscriberTimeoutxs:long
passiveSlavexs:stringGet the passiveSlave
persistenceThreadPriorityxs:integer
persistentxs:stringSets whether or not persistence is enabled or disabled.
populateJMSXUserIDxs:booleanSets whether or not the broker should populate the JMSXUserID header.
populateUserNameInMBeansxs:booleanShould MBeans that support showing the Authenticated User Name information have this value filled in or not.
producerSystemUsagePortionxs:integer
restartAllowedxs:booleanSets if the broker allowed to restart on shutdown.
schedulePeriodForDestinationPurgexs:integer
schedulerDirectoryxs:string
schedulerDirectoryFilexs:string
schedulerSupportxs:string
shutdownOnMasterFailurexs:boolean
shutdownOnSlaveFailurexs:string
splitSystemUsageForProducersConsumersxs:boolean
startxs:booleanSets whether or not the broker is started along with the ApplicationContext it is defined within. Normally you would want the broker to start up along with the ApplicationContext but sometimes when working with JUnit tests you may wish to start and stop the broker explicitly yourself.
startAsyncxs:boolean
storeOpenWireVersionxs:integer
supportFailOverxs:boolean
systemExitOnShutdownxs:string
systemExitOnShutdownExitCodexs:integer
taskRunnerPriorityxs:integer
timeBeforePurgeTempDestinationsxs:integer
tmpDataDirectoryxs:string
useAuthenticatedPrincipalForJMSXUserIDxs:boolean
useJmxxs:stringSets whether or not the Broker's services should be exposed into JMX or not.
useLocalHostBrokerNamexs:boolean
useLoggingForShutdownErrorsxs:booleanSets whether or not we should use commons-logging when reporting errors when shutting down the broker
useMirroredQueuesxs:booleanSets whether or not Mirrored Queues should be supported by default if they have not been explicitly configured.
useShutdownHookxs:booleanSets whether or not we should use a shutdown handler to close down the broker cleanly if the JVM is terminated. It is recommended you leave this enabled.
useTempMirroredQueuesxs:boolean
useVirtualTopicsxs:booleanSets whether or not Virtual Topics should be supported by default if they have not been explicitly configured.
vmConnectorURIxs:string
waitForSlavexs:string
waitForSlaveTimeoutxs:long
ElementTypeDescription
adminView<spring:bean/>Returns the administration view of the broker; used to create and destroy resources such as queues and topics. Note this method returns null if JMX is disabled.
brokerContext<spring:bean/>
consumerSystemUsagesystemUsage
destinationFactory<spring:bean/>
destinationInterceptors(mirroredQueue | virtualDestinationInterceptor)*Sets the destination interceptors to use
destinationPolicypolicyMapSets the destination specific policies available either for exact destinations or for wildcard areas of destinations.
destinations(queue | tempQueue | tempTopic | topic)*Sets the destinations which should be loaded/created on startup
ioExceptionHandlerdefaultIOExceptionHandler | jDBCIOExceptionHandleroverride the Default IOException handler, called when persistence adapter has experiences File or JDBC I/O Exceptions
jmsBridgeConnectors(jmsQueueConnector | jmsTopicConnector)*
jobSchedulerStore<spring:bean/>
managementContextmanagementContext
messageAuthorizationPolicy<spring:bean/>Sets the policy used to decide if the current connection is authorized to consume a given message
networkConnectorURIs(<spring:bean/>)*
networkConnectors(ldapNetworkConnector | multicastNetworkConnector | networkConnector)*Sets the network connectors which this broker will use to connect to other brokers in a federated network
persistenceAdapterjdbcPersistenceAdapter | journalPersistenceAdapter | kahaDB | levelDB | mKahaDB | memoryPersistenceAdapter | replicatedLevelDBSets the persistence adaptor implementation to use for this broker
persistenceFactoryjournalPersistenceAdapterFactory | journaledJDBC
persistenceTaskRunnerFactorytaskRunnerFactory
plugins(authorizationPlugin | connectionDotFilePlugin | destinationDotFilePlugin | destinationPathSeparatorPlugin | discardingDLQBrokerPlugin | forcePersistencyModeBrokerPlugin | jaasAuthenticationPlugin | jaasCertificateAuthenticationPlugin | jaasDualAuthenticationPlugin | loggingBrokerPlugin | multicastTraceBrokerPlugin | partitionBrokerPlugin | redeliveryPlugin | runtimeConfigurationPlugin | simpleAuthenticationPlugin | statisticsBrokerPlugin | timeStampingBrokerPlugin | traceBrokerPathPlugin | udpTraceBrokerPlugin | virtualSelectorCacheBrokerPlugin)*Sets a number of broker plugins to install such as for security authentication or authorization
producerSystemUsagesystemUsage
proxyConnectors(<spring:bean/>)*Sets the network connectors which this broker will use to connect to other brokers in a federated network
regionBrokerdestinationPathSeparatorPlugin | forcePersistencyModeBroker | loggingBrokerPlugin | multicastTraceBrokerPlugin | redeliveryPlugin | timeStampingBrokerPlugin | traceBrokerPathPlugin | udpTraceBrokerPlugin
services(broker | brokerService | database-locker | forwardingBridge | inboundQueueBridge | inboundTopicBridge | jdbcPersistenceAdapter | jmsQueueConnector | jmsTopicConnector | jobSchedulerUsage | journalPersistenceAdapterFactory | journaledJDBC | kahaDB | ldapNetworkConnector | lease-database-locker | levelDB | mKahaDB | managementContext | memoryUsage | multicastNetworkConnector | networkConnector | outboundQueueBridge | outboundTopicBridge | pListStoreImpl | proxyConnector | replicatedLevelDB | shared-file-locker | storeUsage | systemUsage | tempUsage | transact-database-locker)*Sets the services associated with this broker.
shutdownHooks(<spring:bean/>)*Sets hooks to be executed when broker shut down
sslContextsslContext
systemUsagesystemUsage
taskRunnerFactorytaskRunnerFactory
tempDataStorelevelDB | pListStoreImpl | replicatedLevelDB
transportConnectorURIs(<spring:bean/>)*
transportConnectors(transportConnector)*Sets the transport connectors which this broker will listen on for new clients

Element: brokerService

AttributeTypeDescription
advisorySupportxs:stringAllows the support of advisory messages to be disabled for performance reasons.
allowTempAutoCreationOnSendxs:booleanenable if temp destinations need to be propagated through a network when advisorySupport==false. This is used in conjunction with the policy gcInactiveDestinations for matching temps so they can get removed when inactive
brokerIdxs:string
brokerNamexs:stringSets the name of this broker; which must be unique in the network
brokerObjectNamexs:stringSets the JMX ObjectName for this broker
cacheTempDestinationsxs:boolean
consumerSystemUsagePortionxs:integer
dataDirectoryxs:stringSets the directory in which the data files will be stored by default for the JDBC and Journal persistence adaptors.
dataDirectoryFilexs:stringSets the directory in which the data files will be stored by default for the JDBC and Journal persistence adaptors.
dedicatedTaskRunnerxs:boolean
deleteAllMessagesOnStartupxs:stringSets whether or not all messages are deleted on startup - mostly only useful for testing.
enableStatisticsxs:booleanSets whether or not the Broker's services enable statistics or not.
keepDurableSubsActivexs:boolean
maxPurgedDestinationsPerSweepxs:integer
mbeanInvocationTimeoutxs:longGets the time in Milliseconds that an invocation of an MBean method will wait before failing. The default value is to wait forever (zero).
monitorConnectionSplitsxs:boolean
networkConnectorStartAsyncxs:boolean
offlineDurableSubscriberTaskSchedulexs:long
offlineDurableSubscriberTimeoutxs:long
passiveSlavexs:stringGet the passiveSlave
persistenceThreadPriorityxs:integer
persistentxs:stringSets whether or not persistence is enabled or disabled.
populateJMSXUserIDxs:booleanSets whether or not the broker should populate the JMSXUserID header.
populateUserNameInMBeansxs:booleanShould MBeans that support showing the Authenticated User Name information have this value filled in or not.
producerSystemUsagePortionxs:integer
restartAllowedxs:booleanSets if the broker allowed to restart on shutdown.
schedulePeriodForDestinationPurgexs:integer
schedulerDirectoryxs:string
schedulerDirectoryFilexs:string
schedulerSupportxs:string
shutdownOnMasterFailurexs:boolean
shutdownOnSlaveFailurexs:string
splitSystemUsageForProducersConsumersxs:boolean
startAsyncxs:boolean
storeOpenWireVersionxs:integer
supportFailOverxs:boolean
systemExitOnShutdownxs:string
systemExitOnShutdownExitCodexs:integer
taskRunnerPriorityxs:integer
timeBeforePurgeTempDestinationsxs:integer
tmpDataDirectoryxs:string
useAuthenticatedPrincipalForJMSXUserIDxs:boolean
useJmxxs:stringSets whether or not the Broker's services should be exposed into JMX or not.
useLocalHostBrokerNamexs:boolean
useLoggingForShutdownErrorsxs:booleanSets whether or not we should use commons-logging when reporting errors when shutting down the broker
useMirroredQueuesxs:booleanSets whether or not Mirrored Queues should be supported by default if they have not been explicitly configured.
useShutdownHookxs:booleanSets whether or not we should use a shutdown handler to close down the broker cleanly if the JVM is terminated. It is recommended you leave this enabled.
useTempMirroredQueuesxs:boolean
useVirtualTopicsxs:booleanSets whether or not Virtual Topics should be supported by default if they have not been explicitly configured.
vmConnectorURIxs:string
waitForSlavexs:string
waitForSlaveTimeoutxs:long
ElementTypeDescription
adminView<spring:bean/>Returns the administration view of the broker; used to create and destroy resources such as queues and topics. Note this method returns null if JMX is disabled.
brokerContext<spring:bean/>
consumerSystemUsagesystemUsage
destinationFactory<spring:bean/>
destinationInterceptors(mirroredQueue | virtualDestinationInterceptor)*Sets the destination interceptors to use
destinationPolicypolicyMapSets the destination specific policies available either for exact destinations or for wildcard areas of destinations.
destinations(queue | tempQueue | tempTopic | topic)*Sets the destinations which should be loaded/created on startup
ioExceptionHandlerdefaultIOExceptionHandler | jDBCIOExceptionHandleroverride the Default IOException handler, called when persistence adapter has experiences File or JDBC I/O Exceptions
jmsBridgeConnectors(jmsQueueConnector | jmsTopicConnector)*
jobSchedulerStore<spring:bean/>
managementContextmanagementContext
messageAuthorizationPolicy<spring:bean/>Sets the policy used to decide if the current connection is authorized to consume a given message
networkConnectorURIs(<spring:bean/>)*
networkConnectors(ldapNetworkConnector | multicastNetworkConnector | networkConnector)*Sets the network connectors which this broker will use to connect to other brokers in a federated network
persistenceAdapterjdbcPersistenceAdapter | journalPersistenceAdapter | kahaDB | levelDB | mKahaDB | memoryPersistenceAdapter | replicatedLevelDBSets the persistence adaptor implementation to use for this broker
persistenceFactoryjournalPersistenceAdapterFactory | journaledJDBC
persistenceTaskRunnerFactorytaskRunnerFactory
plugins(authorizationPlugin | connectionDotFilePlugin | destinationDotFilePlugin | destinationPathSeparatorPlugin | discardingDLQBrokerPlugin | forcePersistencyModeBrokerPlugin | jaasAuthenticationPlugin | jaasCertificateAuthenticationPlugin | jaasDualAuthenticationPlugin | loggingBrokerPlugin | multicastTraceBrokerPlugin | partitionBrokerPlugin | redeliveryPlugin | runtimeConfigurationPlugin | simpleAuthenticationPlugin | statisticsBrokerPlugin | timeStampingBrokerPlugin | traceBrokerPathPlugin | udpTraceBrokerPlugin | virtualSelectorCacheBrokerPlugin)*Sets a number of broker plugins to install such as for security authentication or authorization
producerSystemUsagesystemUsage
proxyConnectors(<spring:bean/>)*Sets the network connectors which this broker will use to connect to other brokers in a federated network
regionBrokerdestinationPathSeparatorPlugin | forcePersistencyModeBroker | loggingBrokerPlugin | multicastTraceBrokerPlugin | redeliveryPlugin | timeStampingBrokerPlugin | traceBrokerPathPlugin | udpTraceBrokerPlugin
services(broker | brokerService | database-locker | forwardingBridge | inboundQueueBridge | inboundTopicBridge | jdbcPersistenceAdapter | jmsQueueConnector | jmsTopicConnector | jobSchedulerUsage | journalPersistenceAdapterFactory | journaledJDBC | kahaDB | ldapNetworkConnector | lease-database-locker | levelDB | mKahaDB | managementContext | memoryUsage | multicastNetworkConnector | networkConnector | outboundQueueBridge | outboundTopicBridge | pListStoreImpl | proxyConnector | replicatedLevelDB | shared-file-locker | storeUsage | systemUsage | tempUsage | transact-database-locker)*Sets the services associated with this broker.
shutdownHooks(<spring:bean/>)*Sets hooks to be executed when broker shut down
sslContextsslContext
systemUsagesystemUsage
taskRunnerFactorytaskRunnerFactory
tempDataStorelevelDB | pListStoreImpl | replicatedLevelDB
transportConnectorURIs(<spring:bean/>)*
transportConnectors(transportConnector)*Sets the transport connectors which this broker will listen on for new clients

Element: bytesJDBCAdapter

AttributeTypeDescription
batchStatmentsxs:boolean
maxRowsxs:integerthe max value for statement maxRows, used to limit jdbc queries
useExternalMessageReferencesxs:boolean
ElementTypeDescription
statementsstatements

Element: cachedLDAPAuthorizationMap

AttributeTypeDescription
adminPermissionGroupSearchFilterxs:string
authenticationxs:string
connectionPasswordxs:string
connectionProtocolxs:string
connectionURLxs:string
connectionUsernamexs:string
groupNameAttributexs:string
groupObjectClassxs:string
legacyGroupMappingxs:boolean
permissionGroupMemberAttributexs:string
queueSearchBasexs:string
readPermissionGroupSearchFilterxs:string
refreshDisabledxs:boolean
refreshIntervalxs:integer
tempSearchBasexs:string
topicSearchBasexs:string
userNameAttributexs:string
userObjectClassxs:string
writePermissionGroupSearchFilterxs:string

Element: cachedMessageGroupMapFactory

AttributeTypeDescription
cacheSizexs:integer

Element: compositeDemandForwardingBridge

AttributeTypeDescription
createdByDuplexxs:boolean
mbeanObjectNamexs:string
ElementTypeDescription
brokerServicebroker | brokerService
configurationldapNetworkConnector | multicastNetworkConnector | networkConnector
durableDestinations(queue | tempQueue | tempTopic | topic)*
dynamicallyIncludedDestinations(queue | tempQueue | tempTopic | topic)*
excludedDestinations(queue | tempQueue | tempTopic | topic)*
localBroker<spring:bean/>
networkBridgeListener<spring:bean/>
remoteBroker<spring:bean/>
staticallyIncludedDestinations(queue | tempQueue | tempTopic | topic)*

Element: compositeQueue

AttributeTypeDescription
copyMessagexs:booleanSets whether a copy of the message will be sent to each destination. Defaults to true so that the forward destination is set as the destination of the message
forwardOnlyxs:booleanSets if the virtual destination is forward only (and so there is no physical queue to match the virtual queue) or if there is also a physical queue with the same name).
namexs:stringSets the name of this composite destination
ElementTypeDescription
forwardTo(<spring:bean/>)*Sets the list of destinations to forward to

Element: compositeTopic

AttributeTypeDescription
copyMessagexs:booleanSets whether a copy of the message will be sent to each destination. Defaults to true so that the forward destination is set as the destination of the message
forwardOnlyxs:booleanSets if the virtual destination is forward only (and so there is no physical queue to match the virtual queue) or if there is also a physical queue with the same name).
namexs:stringSets the name of this composite destination
ElementTypeDescription
forwardTo(<spring:bean/>)*Sets the list of destinations to forward to

Element: conditionalNetworkBridgeFilterFactory

AttributeTypeDescription
rateDurationxs:integer
rateLimitxs:integer
replayDelayxs:integer
replayWhenNoConsumersxs:boolean

Element: connectionDotFilePlugin

AttributeTypeDescription
filexs:stringSets the destination file name to create the destination diagram

Element: connectionFactory

AttributeTypeDescription
alwaysSessionAsyncxs:booleanIf this flag is not set then a separate thread is not used for dispatching messages for each Session in the Connection. However, a separate thread is always used if there is more than one session, or the session isn't in auto acknowledge or duplicates ok mode. By default this value is set to true and session dispatch happens asynchronously.
alwaysSyncSendxs:booleanSet true if always require messages to be sync sent
auditDepthxs:integer
auditMaximumProducerNumberxs:integer
beanNamexs:string
brokerURLxs:stringSets the connection URL used to connect to the ActiveMQ broker.
checkForDuplicatesxs:boolean
clientIDxs:stringSets the JMS clientID to use for the created connection. Note that this can only be used by one connection at once so generally its a better idea to set the clientID on a Connection
clientIDPrefixxs:stringSets the prefix used by autogenerated JMS Client ID values which are used if the JMS client does not explicitly specify on.
closeTimeoutxs:integerSets the timeout before a close is considered complete. Normally a close() on a connection waits for confirmation from the broker; this allows that operation to timeout to save the client hanging if there is no broker
connectionIDPrefixxs:stringSets the prefix used by connection id generator
consumerFailoverRedeliveryWaitPeriodxs:long
copyMessageOnSendxs:booleanShould a JMS message be copied to a new JMS Message object as part of the send() method in JMS. This is enabled by default to be compliant with the JMS specification. You can disable it if you do not mutate JMS messages after they are sent for a performance boost
disableTimeStampsByDefaultxs:booleanSets whether or not timestamps on messages should be disabled or not. If you disable them it adds a small performance boost.
dispatchAsyncxs:booleanEnables or disables the default setting of whether or not consumers have their messages dispatched synchronously or asynchronously by the broker. For non-durable topics for example we typically dispatch synchronously by default to minimize context switches which boost performance. However sometimes its better to go slower to ensure that a single blocked consumer socket does not block delivery to other consumers.
exclusiveConsumerxs:booleanEnables or disables whether or not queue consumers should be exclusive or not for example to preserve ordering when not using Message Groups
maxThreadPoolSizexs:integer
messagePrioritySupportedxs:boolean
nestedMapAndListEnabledxs:booleanEnables/disables whether or not Message properties and MapMessage entries support Nested Structures of Map and List objects
nonBlockingRedeliveryxs:booleanWhen true a MessageConsumer will not stop Message delivery before re-delivering Messages from a rolled back transaction. This implies that message order will not be preserved and also will result in the TransactedIndividualAck option to be enabled.
objectMessageSerializationDeferedxs:booleanWhen an object is set on an ObjectMessage, the JMS spec requires the object to be serialized by that set method. Enabling this flag causes the object to not get serialized. The object may subsequently get serialized if the message needs to be sent over a socket or stored to disk.
optimizeAcknowledgexs:boolean
optimizeAcknowledgeTimeOutxs:longThe max time in milliseconds between optimized ack batches
optimizedAckScheduledAckIntervalxs:longGets the configured time interval that is used to force all MessageConsumers that have optimizedAcknowledge enabled to send an ack for any outstanding Message Acks. By default this value is set to zero meaning that the consumers will not do any background Message acknowledgment.
optimizedMessageDispatchxs:booleanIf this flag is set then an larger prefetch limit is used - only applicable for durable topic subscribers.
passwordxs:stringSets the JMS password used for connections created from this factory
producerWindowSizexs:integer
sendAcksAsyncxs:boolean
sendTimeoutxs:integer
statsEnabledxs:boolean
transactedIndividualAckxs:booleanwhen true, submit individual transacted acks immediately rather than with transaction completion. This allows the acks to represent delivery status which can be persisted on rollback Used in conjunction with org.apache.activemq.store.kahadb.KahaDBPersistenceAdapter#setRewriteOnRedelivery(boolean) true
useAsyncSendxs:booleanForces the use of Async Sends which adds a massive performance boost; but means that the send() method will return immediately whether the message has been sent or not which could lead to message loss.
useBeanNameAsClientIdPrefixxs:boolean
useCompressionxs:booleanEnables the use of compression of the message bodies
useDedicatedTaskRunnerxs:boolean
useRetroactiveConsumerxs:booleanSets whether or not retroactive consumers are enabled. Retroactive consumers allow non-durable topic subscribers to receive old messages that were published before the non-durable subscriber started.
userNamexs:stringSets the JMS userName used by connections created by this factory
warnAboutUnstartedConnectionTimeoutxs:longEnables the timeout from a connection creation to when a warning is generated if the connection is not properly started via {@link Connection#start()} and a message is received by a consumer. It is a very common gotcha to forget to start the connection so this option makes the default case to create a warning if the user forgets. To disable the warning just set the value to < 0 (say -1).
watchTopicAdvisoriesxs:boolean
ElementTypeDescription
blobTransferPolicy<spring:bean/>Sets the policy used to describe how out-of-band BLOBs (Binary Large OBjects) are transferred from producers to brokers to consumers
clientIdGenerator<spring:bean/>
clientInternalExceptionListener<spring:bean/>Allows an {@link ClientInternalExceptionListener} to be configured on the ConnectionFactory so that when this factory is used by frameworks which don't expose the Connection such as Spring JmsTemplate, you can register an exception listener.

Note: access to this clientInternalExceptionListener will not be serialized if it is associated with more than on connection (as it will be if more than one connection is subsequently created by this connection factory)

connectionIdGenerator<spring:bean/>
exceptionListener<spring:bean/>Allows an {@link ExceptionListener} to be configured on the ConnectionFactory so that when this factory is used by frameworks which don't expose the Connection such as Spring JmsTemplate, you can register an exception listener.

Note: access to this exceptionLinstener will not be serialized if it is associated with more than on connection (as it will be if more than one connection is subsequently created by this connection factory)

prefetchPolicyprefetchPolicySets the prefetch policy for consumers created by this connection.
properties<spring:bean/>Get the properties from this instance for storing in JNDI
redeliveryPolicyredeliveryPolicySets the global default redelivery policy to be used when a message is delivered but the session is rolled back
redeliveryPolicyMapredeliveryPolicyMapSets the global redelivery policy mapping to be used when a message is delivered but the session is rolled back
rejectedTaskHandler<spring:bean/>
sessionTaskRunnertaskRunnerFactory
transformer<spring:bean/>Sets the transformer used to transform messages before they are sent on to the JMS bus or when they are received from the bus but before they are delivered to the JMS client
transportListener<spring:bean/>Allows a listener to be configured on the ConnectionFactory so that when this factory is used with frameworks which don't expose the Connection such as Spring JmsTemplate, you can still register a transport listener.

Element: constantPendingMessageLimitStrategy

AttributeTypeDescription
limitxs:integer

Element: database-locker

AttributeTypeDescription
createTablesOnStartupxs:boolean
failIfLockedxs:boolean
lockAcquireSleepIntervalxs:long
namexs:string
queryTimeoutxs:integer
ElementTypeDescription
dataSource<spring:bean/>
exceptionHandler<spring:bean/>
lockablejdbcPersistenceAdapter | journalPersistenceAdapterFactory | journaledJDBC | kahaDB | levelDB | mKahaDB | replicatedLevelDB
statementsstatements

Element: db2JDBCAdapter

AttributeTypeDescription
batchStatmentsxs:boolean
maxRowsxs:integerthe max value for statement maxRows, used to limit jdbc queries
useExternalMessageReferencesxs:boolean
ElementTypeDescription
statementsstatements

Element: defaultIOExceptionHandler

AttributeTypeDescription
ignoreAllErrorsxs:boolean
ignoreNoSpaceErrorsxs:boolean
ignoreSQLExceptionsxs:boolean
noSpaceMessagexs:string
resumeCheckSleepPeriodxs:long
sqlExceptionMessagexs:string
stopStartConnectorsxs:boolean
ElementTypeDescription
brokerServicebroker | brokerService

Element: defaultJDBCAdapter

AttributeTypeDescription
batchStatmentsxs:boolean
maxRowsxs:integerthe max value for statement maxRows, used to limit jdbc queries
useExternalMessageReferencesxs:boolean
ElementTypeDescription
statementsstatements

Element: defaultNetworkBridgeFilterFactory

Element: defaultUsageCapacity

AttributeTypeDescription
limitxs:long

Element: demandForwardingBridge

AttributeTypeDescription
createdByDuplexxs:boolean
mbeanObjectNamexs:string
ElementTypeDescription
brokerServicebroker | brokerService
configurationldapNetworkConnector | multicastNetworkConnector | networkConnector
durableDestinations(queue | tempQueue | tempTopic | topic)*
dynamicallyIncludedDestinations(queue | tempQueue | tempTopic | topic)*
excludedDestinations(queue | tempQueue | tempTopic | topic)*
localBroker<spring:bean/>
networkBridgeListener<spring:bean/>
remoteBroker<spring:bean/>
staticallyIncludedDestinations(queue | tempQueue | tempTopic | topic)*

Element: destinationDotFilePlugin

AttributeTypeDescription
filexs:stringSets the destination file name to create the destination diagram

Element: destinationEntry

AttributeTypeDescription
queuexs:stringA helper method to set the destination from a configuration file
tempQueuexs:boolean
tempTopicxs:boolean
topicxs:stringA helper method to set the destination from a configuration file
ElementTypeDescription
destinationqueue | tempQueue | tempTopic | topic
valueauthorizationEntry | destinationEntry | filteredKahaDB | policyEntry | redeliveryPolicy | tempDestinationAuthorizationEntry

Element: destinationPathSeparatorPlugin

AttributeTypeDescription
pathSeparatorxs:string
ElementTypeDescription
adminConnectionContext<spring:bean/>
nextdestinationPathSeparatorPlugin | forcePersistencyModeBroker | loggingBrokerPlugin | multicastTraceBrokerPlugin | redeliveryPlugin | timeStampingBrokerPlugin | traceBrokerPathPlugin | udpTraceBrokerPlugin

Element: discarding

AttributeTypeDescription
enableAuditxs:boolean
processExpiredxs:boolean
processNonPersistentxs:boolean
ElementTypeDescription
deadLetterQueuequeue | tempQueue | tempTopic | topic

Element: discardingDLQBrokerPlugin

AttributeTypeDescription
dropAllxs:boolean
dropOnlyxs:string
dropTemporaryQueuesxs:boolean
dropTemporaryTopicsxs:boolean
reportIntervalxs:integer

Element: fileCursor

Element: fileDurableSubscriberCursor

Element: fileQueueCursor

Element: filteredDestination

AttributeTypeDescription
queuexs:stringSets the destination property to the given queue name
selectorxs:stringSets the JMS selector used to filter messages before forwarding them to this destination
topicxs:stringSets the destination property to the given topic name
ElementTypeDescription
destinationqueue | tempQueue | tempTopic | topicThe destination to send messages to if they match the filter
filter<spring:bean/>

Element: filteredKahaDB

AttributeTypeDescription
perDestinationxs:boolean
queuexs:stringA helper method to set the destination from a configuration file
tempQueuexs:boolean
tempTopicxs:boolean
topicxs:stringA helper method to set the destination from a configuration file
ElementTypeDescription
adapterjdbcPersistenceAdapter | journalPersistenceAdapter | kahaDB | levelDB | mKahaDB | memoryPersistenceAdapter | replicatedLevelDB
destinationqueue | tempQueue | tempTopic | topic
persistenceAdapterjdbcPersistenceAdapter | journalPersistenceAdapter | kahaDB | levelDB | mKahaDB | memoryPersistenceAdapter | replicatedLevelDB

Element: fixedCountSubscriptionRecoveryPolicy

AttributeTypeDescription
maximumSizexs:integerSets the maximum number of messages that this destination will hold around in RAM
ElementTypeDescription
brokerdestinationPathSeparatorPlugin | forcePersistencyModeBroker | loggingBrokerPlugin | multicastTraceBrokerPlugin | redeliveryPlugin | timeStampingBrokerPlugin | traceBrokerPathPlugin | udpTraceBrokerPlugin

Element: fixedSizedSubscriptionRecoveryPolicy

AttributeTypeDescription
maximumSizexs:integerSets the maximum amount of RAM in bytes that this buffer can hold in RAM
useSharedBufferxs:boolean
ElementTypeDescription
brokerdestinationPathSeparatorPlugin | forcePersistencyModeBroker | loggingBrokerPlugin | multicastTraceBrokerPlugin | redeliveryPlugin | timeStampingBrokerPlugin | traceBrokerPathPlugin | udpTraceBrokerPlugin
buffer<spring:bean/>

Element: forcePersistencyModeBroker

AttributeTypeDescription
persistenceFlagxs:boolean
ElementTypeDescription
adminConnectionContext<spring:bean/>
nextdestinationPathSeparatorPlugin | forcePersistencyModeBroker | loggingBrokerPlugin | multicastTraceBrokerPlugin | redeliveryPlugin | timeStampingBrokerPlugin | traceBrokerPathPlugin | udpTraceBrokerPlugin

Element: forcePersistencyModeBrokerPlugin

AttributeTypeDescription
persistenceFlagxs:booleanSets the persistency mode.

Element: forwardingBridge

AttributeTypeDescription
clientIdxs:string
destinationFilterxs:string
dispatchAsyncxs:boolean
prefetchSizexs:integer
useCompressionxs:boolean
ElementTypeDescription
localBroker<spring:bean/>
networkBridgeFailedListener<spring:bean/>
remoteBroker<spring:bean/>

Element: hsqldb-jdbc-adapter

AttributeTypeDescription
batchStatmentsxs:boolean
maxRowsxs:integerthe max value for statement maxRows, used to limit jdbc queries
useExternalMessageReferencesxs:boolean
ElementTypeDescription
statementsstatements

Element: imageBasedJDBCAdaptor

AttributeTypeDescription
batchStatmentsxs:boolean
maxRowsxs:integerthe max value for statement maxRows, used to limit jdbc queries
useExternalMessageReferencesxs:boolean
ElementTypeDescription
statementsstatements

Element: inboundQueueBridge

AttributeTypeDescription
doHandleReplyToxs:boolean
inboundQueueNamexs:stringSets the queue name used for the inbound queue, if the outbound queue name has not been set, then this method uses the same name to configure the outbound queue name.
localQueueNamexs:string
selectorxs:string
ElementTypeDescription
consumer<spring:bean/>
consumerConnection<spring:bean/>
consumerQueuequeue
jmsConnectorjmsQueueConnector | jmsTopicConnector
jmsMessageConvertorsimpleJmsMessageConvertor
producerConnection<spring:bean/>
producerQueuequeue

Element: inboundTopicBridge

AttributeTypeDescription
consumerNamexs:string
doHandleReplyToxs:boolean
inboundTopicNamexs:stringSets the topic name used for the inbound topic, if the outbound topic name has not been set, then this method uses the same name to configure the outbound topic name.
localTopicNamexs:string
selectorxs:string
ElementTypeDescription
consumer<spring:bean/>
consumerConnection<spring:bean/>
consumerTopictopic
jmsConnectorjmsQueueConnector | jmsTopicConnector
jmsMessageConvertorsimpleJmsMessageConvertor
producerConnection<spring:bean/>
producerTopictopic

Element: individualDeadLetterStrategy

AttributeTypeDescription
destinationPerDurableSubscriberxs:booleansets whether durable topic subscriptions are to get individual dead letter destinations. When true, the DLQ is of the form 'topicPrefix.clientId:subscriptionName' The default is false.
enableAuditxs:boolean
processExpiredxs:boolean
processNonPersistentxs:boolean
queuePrefixxs:stringSets the prefix to use for all dead letter queues for queue messages
queueSuffixxs:stringSets the suffix to use for all dead letter queues for queue messages
topicPrefixxs:stringSets the prefix to use for all dead letter queues for topic messages
topicSuffixxs:stringSets the suffix to use for all dead letter queues for topic messages
useQueueForQueueMessagesxs:booleanSets whether a queue or topic should be used for queue messages sent to a DLQ. The default is to use a Queue
useQueueForTopicMessagesxs:booleanSets whether a queue or topic should be used for topic messages sent to a DLQ. The default is to use a Queue

Element: informixJDBCAdapter

AttributeTypeDescription
batchStatmentsxs:boolean
maxRowsxs:integerthe max value for statement maxRows, used to limit jdbc queries
useExternalMessageReferencesxs:boolean
ElementTypeDescription
statementsstatements

Element: jDBCIOExceptionHandler

AttributeTypeDescription
ignoreAllErrorsxs:boolean
ignoreNoSpaceErrorsxs:boolean
ignoreSQLExceptionsxs:boolean
noSpaceMessagexs:string
resumeCheckSleepPeriodxs:long
sqlExceptionMessagexs:string
stopStartConnectorsxs:boolean
ElementTypeDescription
brokerServicebroker | brokerService

Element: jaasAuthenticationPlugin

AttributeTypeDescription
configurationxs:stringSets the JAAS configuration domain name used
discoverLoginConfigxs:booleanEnables or disables the auto-discovery of the login.config file for JAAS to initialize itself. This flag is enabled by default such that if the java.security.auth.login.config system property is not defined then it is set to the location of the login.config file on the classpath.

Element: jaasCertificateAuthenticationPlugin

AttributeTypeDescription
configurationxs:stringSets the JAAS configuration domain name used
discoverLoginConfigxs:booleanEnables or disables the auto-discovery of the login.config file for JAAS to initialize itself. This flag is enabled by default such that if the java.security.auth.login.config system property is not defined then it is set to the location of the login.config file on the classpath.

Element: jaasDualAuthenticationPlugin

AttributeTypeDescription
configurationxs:stringSets the JAAS configuration domain name used
discoverLoginConfigxs:booleanEnables or disables the auto-discovery of the login.config file for JAAS to initialize itself. This flag is enabled by default such that if the java.security.auth.login.config system property is not defined then it is set to the location of the login.config file on the classpath.
sslConfigurationxs:stringSet the JAAS SSL configuration domain

Element: jdbcPersistenceAdapter

AttributeTypeDescription
auditRecoveryDepthxs:integer
brokerNamexs:string
changeAutoCommitAllowedxs:booleanWhether the JDBC driver allows to set the auto commit. Some drivers does not allow changing the auto commit. The default value is true.
cleanupPeriodxs:integerSets the number of milliseconds until the database is attempted to be cleaned up for durable topics
createTablesOnStartupxs:booleanSets whether or not tables are created on startup
dataDirectoryxs:string
dataDirectoryFilexs:string
directoryxs:string
enableAuditxs:boolean
lockAcquireSleepIntervalxs:long
lockKeepAlivePeriodxs:long
maxAuditDepthxs:integer
maxProducersToAuditxs:integer
maxRowsxs:integer
transactionIsolationxs:integerset the Transaction isolation level to something other that TRANSACTION_READ_UNCOMMITTED This allowable dirty isolation level may not be achievable in clustered DB environments so a more restrictive and expensive option may be needed like TRANSACTION_REPEATABLE_READ see isolation level constants in {@link java.sql.Connection}
useDatabaseLockxs:boolean
useExternalMessageReferencesxs:boolean
useLockxs:boolean
ElementTypeDescription
adapteraxionJDBCAdapter | blobJDBCAdapter | bytesJDBCAdapter | db2JDBCAdapter | defaultJDBCAdapter | hsqldb-jdbc-adapter | imageBasedJDBCAdaptor | informixJDBCAdapter | maxdb-jdbc-adapter | mysql-jdbc-adapter | oracleBlobJDBCAdapter | oracleJDBCAdapter | postgresql-jdbc-adapter | streamJDBCAdapter | sybase-jdbc-adapter | transact-jdbc-adapter
brokerServicebroker | brokerService
dataSource<spring:bean/>
databaseLockerdatabase-locker | lease-database-locker | shared-file-locker | transact-database-lockerSets the database locker strategy to use to lock the database on startup
ds<spring:bean/>
lockDataSource<spring:bean/>
lockerdatabase-locker | lease-database-locker | shared-file-locker | transact-database-locker
scheduledThreadPoolExecutor<spring:bean/>
statementsstatements
usageManagersystemUsage
wireFormat<spring:bean/>

Element: jmsQueueConnector

AttributeTypeDescription
jndiLocalTemplatexs:string
jndiOutboundTemplatexs:string
localClientIdxs:string
localConnectionFactoryNamexs:string
localPasswordxs:string
localUsernamexs:string
namexs:string
outboundClientIdxs:string
outboundPasswordxs:string
outboundQueueConnectionFactoryNamexs:string
outboundUsernamexs:string
preferJndiDestinationLookupxs:booleanSets whether the connector should prefer to first try to find a destination in JNDI before using JMS semantics to create a Destination. By default the connector will first use JMS semantics and then fall-back to JNDI lookup, setting this value to true will reverse that ordering.
replyToDestinationCacheSizexs:integer
ElementTypeDescription
brokerServicebroker | brokerServiceOne way to configure the local connection - this is called by The BrokerService when the Connector is embedded
inboundMessageConvertorsimpleJmsMessageConvertor
inboundQueueBridges(inboundQueueBridge)*
localQueueConnection<spring:bean/>
localQueueConnectionFactoryconnectionFactory | xaConnectionFactory
outboundMessageConvertorsimpleJmsMessageConvertor
outboundQueueBridges(outboundQueueBridge)*
outboundQueueConnection<spring:bean/>
outboundQueueConnectionFactoryconnectionFactory | xaConnectionFactory
reconnectionPolicyreconnectionPolicy

Element: jmsTopicConnector

AttributeTypeDescription
jndiLocalTemplatexs:string
jndiOutboundTemplatexs:string
localClientIdxs:string
localConnectionFactoryNamexs:string
localPasswordxs:string
localUsernamexs:string
namexs:string
outboundClientIdxs:string
outboundPasswordxs:string
outboundTopicConnectionFactoryNamexs:string
outboundUsernamexs:string
preferJndiDestinationLookupxs:booleanSets whether the connector should prefer to first try to find a destination in JNDI before using JMS semantics to create a Destination. By default the connector will first use JMS semantics and then fall-back to JNDI lookup, setting this value to true will reverse that ordering.
replyToDestinationCacheSizexs:integer
ElementTypeDescription
brokerServicebroker | brokerServiceOne way to configure the local connection - this is called by The BrokerService when the Connector is embedded
inboundMessageConvertorsimpleJmsMessageConvertor
inboundTopicBridges(inboundTopicBridge)*
localTopicConnection<spring:bean/>
localTopicConnectionFactoryconnectionFactory | xaConnectionFactory
outboundMessageConvertorsimpleJmsMessageConvertor
outboundTopicBridges(outboundTopicBridge)*
outboundTopicConnection<spring:bean/>
outboundTopicConnectionFactoryconnectionFactory | xaConnectionFactory
reconnectionPolicyreconnectionPolicy

Element: jobSchedulerUsage

AttributeTypeDescription
limitxs:stringSets the memory limit in bytes. Setting the limit in bytes will set the usagePortion to 0 since the UsageManager is not going to be portion based off the parent. When set using Xbean, values of the form "20 Mb", "1024kb", and "1g" can be used
namexs:string
percentUsagexs:integer
percentUsageMinDeltaxs:stringSets the minimum number of percentage points the usage has to change before a UsageListener event is fired by the manager.
pollingTimexs:integer
usagePortionxs:float
ElementTypeDescription
executor<spring:bean/>
limiterdefaultUsageCapacity | usageCapacity
parent<spring:bean/>
store<spring:bean/>

Element: journalPersistenceAdapter

AttributeTypeDescription
brokerNamexs:string
directoryxs:string
maxCheckpointMessageAddSizexs:integer
maxCheckpointWorkersxs:integer
useExternalMessageReferencesxs:boolean
ElementTypeDescription
brokerServicebroker | brokerService
journal<spring:bean/>
longTermPersistencejdbcPersistenceAdapter | journalPersistenceAdapter | kahaDB | levelDB | mKahaDB | memoryPersistenceAdapter | replicatedLevelDB
persistenceAdapterjdbcPersistenceAdapter | journalPersistenceAdapter | kahaDB | levelDB | mKahaDB | memoryPersistenceAdapter | replicatedLevelDB
taskRunnerFactorytaskRunnerFactory
usageManagersystemUsage

Element: journalPersistenceAdapterFactory

AttributeTypeDescription
createTablesOnStartupxs:booleanSets whether or not tables are created on startup
dataDirectoryxs:string
dataDirectoryFilexs:string
journalArchiveDirectoryxs:string
journalLogFileSizexs:stringSets the size of the journal log files When set using Xbean, values of the form "20 Mb", "1024kb", and "1g" can be used
journalLogFilesxs:integerSets the number of journal log files to use
journalThreadPriorityxs:integerSets the thread priority of the journal thread
lockKeepAlivePeriodxs:long
useDatabaseLockxs:booleanSets whether or not an exclusive database lock should be used to enable JDBC Master/Slave. Enabled by default.
useDedicatedTaskRunnerxs:boolean
useJournalxs:booleanEnables or disables the use of the journal. The default is to use the journal
useLockxs:boolean
useQuickJournalxs:booleanEnables or disables the use of quick journal, which keeps messages in the journal and just stores a reference to the messages in JDBC. Defaults to false so that messages actually reside long term in the JDBC database.
ElementTypeDescription
adapteraxionJDBCAdapter | blobJDBCAdapter | bytesJDBCAdapter | db2JDBCAdapter | defaultJDBCAdapter | hsqldb-jdbc-adapter | imageBasedJDBCAdaptor | informixJDBCAdapter | maxdb-jdbc-adapter | mysql-jdbc-adapter | oracleBlobJDBCAdapter | oracleJDBCAdapter | postgresql-jdbc-adapter | streamJDBCAdapter | sybase-jdbc-adapter | transact-jdbc-adapter
brokerServicebroker | brokerService
dataSource<spring:bean/>
jdbcAdapterjdbcPersistenceAdapter
journal<spring:bean/>
lockerdatabase-locker | lease-database-locker | shared-file-locker | transact-database-locker
statementsstatements
taskRunnerFactorytaskRunnerFactory

Element: journaledJDBC

AttributeTypeDescription
createTablesOnStartupxs:booleanSets whether or not tables are created on startup
dataDirectoryxs:string
dataDirectoryFilexs:string
journalArchiveDirectoryxs:string
journalLogFileSizexs:stringSets the size of the journal log files When set using Xbean, values of the form "20 Mb", "1024kb", and "1g" can be used
journalLogFilesxs:integerSets the number of journal log files to use
journalThreadPriorityxs:integerSets the thread priority of the journal thread
lockKeepAlivePeriodxs:long
useDatabaseLockxs:booleanSets whether or not an exclusive database lock should be used to enable JDBC Master/Slave. Enabled by default.
useDedicatedTaskRunnerxs:boolean
useJournalxs:booleanEnables or disables the use of the journal. The default is to use the journal
useLockxs:boolean
useQuickJournalxs:booleanEnables or disables the use of quick journal, which keeps messages in the journal and just stores a reference to the messages in JDBC. Defaults to false so that messages actually reside long term in the JDBC database.
ElementTypeDescription
adapteraxionJDBCAdapter | blobJDBCAdapter | bytesJDBCAdapter | db2JDBCAdapter | defaultJDBCAdapter | hsqldb-jdbc-adapter | imageBasedJDBCAdaptor | informixJDBCAdapter | maxdb-jdbc-adapter | mysql-jdbc-adapter | oracleBlobJDBCAdapter | oracleJDBCAdapter | postgresql-jdbc-adapter | streamJDBCAdapter | sybase-jdbc-adapter | transact-jdbc-adapter
brokerServicebroker | brokerService
dataSource<spring:bean/>
jdbcAdapterjdbcPersistenceAdapter
journal<spring:bean/>
lockerdatabase-locker | lease-database-locker | shared-file-locker | transact-database-locker
statementsstatements
taskRunnerFactorytaskRunnerFactory

Element: kahaDB

AttributeTypeDescription
archiveCorruptedIndexxs:boolean
archiveDataLogsxs:boolean
brokerNamexs:string
checkForCorruptJournalFilesxs:boolean
checkpointIntervalxs:longGet the checkpointInterval
checksumJournalFilesxs:boolean
cleanupIntervalxs:longGet the cleanupInterval
concurrentStoreAndDispatchQueuesxs:boolean
concurrentStoreAndDispatchTopicsxs:boolean
databaseLockedWaitDelayxs:integer
directoryxs:stringGet the directory
directoryArchivexs:string
enableIndexDiskSyncsxs:boolean
enableIndexPageCachingxs:boolean
enableIndexRecoveryFilexs:boolean
enableIndexWriteAsyncxs:booleanGet the enableIndexWriteAsync
enableJournalDiskSyncsxs:booleanGet the enableJournalDiskSyncs
failoverProducersAuditDepthxs:integerset the audit window depth for duplicate suppression (should exceed the max transaction batch)
forceRecoverIndexxs:boolean
ignoreMissingJournalfilesxs:booleanGet the ignoreMissingJournalfiles
indexCacheSizexs:stringGet the indexCacheSize
indexLFUEvictionFactorxs:float
indexWriteBatchSizexs:stringGet the indexWriteBatchSize
journalMaxFileLengthxs:stringGet the journalMaxFileLength
journalMaxWriteBatchSizexs:stringGet the journalMaxWriteBatchSize
lockKeepAlivePeriodxs:long
maxAsyncJobsxs:integer
maxFailoverProducersToTrackxs:integerSet the max number of producers (LRU cache) to track for duplicate sends
rewriteOnRedeliveryxs:booleanWhen true, persist the redelivery status such that the message redelivery flag can survive a broker failure used with org.apache.activemq.ActiveMQConnectionFactory#setTransactedIndividualAck(boolean) true
useIndexLFRUEvictionxs:boolean
useLockxs:boolean
ElementTypeDescription
brokerServicebroker | brokerService
lockerdatabase-locker | lease-database-locker | shared-file-locker | transact-database-locker
transactionIdTransformer<spring:bean/>
usageManagersystemUsage

Element: lDAPAuthorizationMap

AttributeTypeDescription
adminAttributexs:string
adminBasexs:string
advisorySearchBasexs:string
authenticationxs:string
connectionPasswordxs:string
connectionProtocolxs:string
connectionURLxs:string
connectionUsernamexs:string
initialContextFactoryxs:string
queueSearchSubtreeBoolxs:boolean
readAttributexs:string
readBasexs:string
tempSearchBasexs:string
topicSearchSubtreeBoolxs:boolean
useAdvisorySearchBasexs:boolean
writeAttributexs:string
writeBasexs:string
ElementTypeDescription
context<spring:bean/>
options<spring:bean/>
queueSearchMatchingFormat<spring:bean/>
topicSearchMatchingFormat<spring:bean/>

Element: lastImageSubscriptionRecoveryPolicy

ElementTypeDescription
brokerdestinationPathSeparatorPlugin | forcePersistencyModeBroker | loggingBrokerPlugin | multicastTraceBrokerPlugin | redeliveryPlugin | timeStampingBrokerPlugin | traceBrokerPathPlugin | udpTraceBrokerPlugin

Element: ldapNetworkConnector

AttributeTypeDescription
advisoryForFailedForwardxs:boolean
alwaysSyncSendxs:boolean
anonymousAuthenticationxs:booleansets LDAP anonymous authentication access credentials
basexs:stringsets the base LDAP dn used for lookup operations
bridgeTempDestinationsxs:boolean
brokerNamexs:string
brokerURLxs:string
conduitSubscriptionsxs:boolean
consumerPriorityBasexs:integer
consumerTTLxs:integer
decreaseNetworkConsumerPriorityxs:boolean
destinationFilterxs:string
dispatchAsyncxs:boolean
duplexxs:boolean
dynamicOnlyxs:boolean
localUrixs:string
messageTTLxs:integer
namexs:string
networkTTLxs:integer
objectNamexs:string
passwordxs:stringsets the LDAP password for access credentials
prefetchSizexs:string
searchEventListenerxs:booleanenables/disable a persistent search to the LDAP server as defined in draft-ietf-ldapext-psearch-03.txt (2.16.840.1.113730.3.4.3)
searchFilterxs:stringsets the LDAP search filter as defined in RFC 2254
searchScopexs:stringsets the LDAP search scope
staticBridgexs:boolean
suppressDuplicateQueueSubscriptionsxs:boolean
suppressDuplicateTopicSubscriptionsxs:boolean
urixs:stringreturns the next URI from the configured list
useBrokerNameAsIdSeesxs:boolean
useCompressionxs:boolean
userxs:stringsets the LDAP user for access credentials
userNamexs:string
ElementTypeDescription
brokerServicebroker | brokerService
connectionFilter<spring:bean/>
durableDestinations(<spring:bean/>)*
dynamicallyIncludedDestinations(<spring:bean/>)*
excludedDestinations(<spring:bean/>)*
staticallyIncludedDestinations(<spring:bean/>)*

Element: lease-database-locker

AttributeTypeDescription
createTablesOnStartupxs:boolean
failIfLockedxs:boolean
leaseHolderIdxs:string
lockAcquireSleepIntervalxs:long
maxAllowableDiffFromDBTimexs:integer
namexs:string
queryTimeoutxs:integer
ElementTypeDescription
dataSource<spring:bean/>
lockablejdbcPersistenceAdapter | journalPersistenceAdapterFactory | journaledJDBC | kahaDB | levelDB | mKahaDB | replicatedLevelDB
statementsstatements

Element: levelDB

AttributeTypeDescription
asyncBufferSizexs:integer
autoCompactionRatioxs:integer
brokerNamexs:string
directoryxs:string
failoverProducersAuditDepthxs:integer
flushDelayxs:integer
indexBlockRestartIntervalxs:integer
indexBlockSizexs:integer
indexCacheSizexs:long
indexCompressionxs:string
indexFactoryxs:string
indexMaxOpenFilesxs:integer
indexWriteBufferSizexs:integer
lockKeepAlivePeriodxs:long
logCompressionxs:string
logDirectoryxs:string
logSizexs:long
maxFailoverProducersToTrackxs:integer
monitorStatsxs:boolean
paranoidChecksxs:boolean
syncxs:boolean
useLockxs:boolean
verifyChecksumsxs:boolean
ElementTypeDescription
brokerServicebroker | brokerService
lockerdatabase-locker | lease-database-locker | shared-file-locker | transact-database-locker
transactionIdTransformer<spring:bean/>
usageManagersystemUsage

Element: loggingBrokerPlugin

AttributeTypeDescription
logAllxs:booleanLogger all Events that go through the Plugin
logConnectionEventsxs:booleanLogger Events that are related to connections
logConsumerEventsxs:booleanLogger Events that are related to Consumers
logInternalEventsxs:booleanLogger Events that are normally internal to the broker
logMessageEventsxs:booleanLogger Events that are related to message processing
logProducerEventsxs:booleanLogger Events that are related to Producers
logSessionEventsxs:booleanLogger Events that are related to sessions
logTransactionEventsxs:booleanLogger Events that are related to transaction processing
perDestinationLoggerxs:boolean
ElementTypeDescription
adminConnectionContext<spring:bean/>
nextdestinationPathSeparatorPlugin | forcePersistencyModeBroker | loggingBrokerPlugin | multicastTraceBrokerPlugin | redeliveryPlugin | timeStampingBrokerPlugin | traceBrokerPathPlugin | udpTraceBrokerPlugin

Element: mKahaDB

AttributeTypeDescription
brokerNamexs:string
directoryxs:string
journalMaxFileLengthxs:stringSet the max file length of the transaction journal When set using Xbean, values of the form "20 Mb", "1024kb", and "1g" can be used
journalWriteBatchSizexs:stringSet the max write batch size of the transaction journal When set using Xbean, values of the form "20 Mb", "1024kb", and "1g" can be used
lockKeepAlivePeriodxs:long
useLockxs:boolean
ElementTypeDescription
brokerServicebroker | brokerService
filteredPersistenceAdapters(<spring:bean/>)*Sets the FilteredKahaDBPersistenceAdapter entries
lockerdatabase-locker | lease-database-locker | shared-file-locker | transact-database-locker
transactionStore<spring:bean/>
usageManagersystemUsage

Element: managementContext

AttributeTypeDescription
allowRemoteAddressInMBeanNamesxs:boolean
brokerNamexs:stringGets the broker name this context is used by, may be null if the broker name was not set.
connectorHostxs:stringGet the connectorHost
connectorPathxs:string
connectorPortxs:string
createConnectorxs:string
createMBeanServerxs:boolean
findTigerMbeanServerxs:booleanEnables/disables the searching for the Java 5 platform MBeanServer
jmxDomainNamexs:string
rmiServerPortxs:string
useMBeanServerxs:boolean
ElementTypeDescription
MBeanServer<spring:bean/>Get the MBeanServer
environment<spring:bean/>
server<spring:bean/>

Element: maxdb-jdbc-adapter

AttributeTypeDescription
batchStatmentsxs:boolean
maxRowsxs:integerthe max value for statement maxRows, used to limit jdbc queries
useExternalMessageReferencesxs:boolean
ElementTypeDescription
statementsstatements

Element: memoryPersistenceAdapter

AttributeTypeDescription
brokerNamexs:string
createTransactionStorexs:boolean
directoryxs:string
useExternalMessageReferencesxs:boolean
ElementTypeDescription
usageManagersystemUsage

Element: memoryUsage

AttributeTypeDescription
limitxs:stringSets the memory limit in bytes. Setting the limit in bytes will set the usagePortion to 0 since the UsageManager is not going to be portion based off the parent. When set using Xbean, values of the form "20 Mb", "1024kb", and "1g" can be used
namexs:string
percentOfJvmHeapxs:integer
percentUsagexs:integer
percentUsageMinDeltaxs:stringSets the minimum number of percentage points the usage has to change before a UsageListener event is fired by the manager.
pollingTimexs:integer
portionxs:float
usagexs:long
usagePortionxs:float
ElementTypeDescription
executor<spring:bean/>
limiterdefaultUsageCapacity | usageCapacity
parent<spring:bean/>

Element: messageGroupHashBucketFactory

AttributeTypeDescription
bucketCountxs:integerSets the number of hash buckets to use for the message group functionality. This is only applicable to using message groups to parallelize processing of a queue while preserving order across an individual JMSXGroupID header value. This value sets the number of hash buckets that will be used (i.e. the maximum possible concurrency).
cacheSizexs:integer

Element: mirroredQueue

AttributeTypeDescription
copyMessagexs:booleanSets whether a copy of the message will be sent to each destination. Defaults to true so that the forward destination is set as the destination of the message
postfixxs:stringSets any postix used to identify the queue consumers
prefixxs:stringSets the prefix wildcard used to identify the queue consumers for a given topic
ElementTypeDescription
brokerServicebroker | brokerService

Element: multicastNetworkConnector

AttributeTypeDescription
advisoryForFailedForwardxs:boolean
alwaysSyncSendxs:boolean
bridgeTempDestinationsxs:boolean
brokerNamexs:string
brokerURLxs:string
conduitSubscriptionsxs:boolean
consumerPriorityBasexs:integer
consumerTTLxs:integer
decreaseNetworkConsumerPriorityxs:boolean
destinationFilterxs:string
dispatchAsyncxs:boolean
duplexxs:boolean
dynamicOnlyxs:boolean
localUrixs:string
messageTTLxs:integer
namexs:string
networkTTLxs:integer
objectNamexs:string
passwordxs:string
prefetchSizexs:string
remoteURIxs:stringSets the remote transport URI to some group transport like multicast://address:port
staticBridgexs:boolean
suppressDuplicateQueueSubscriptionsxs:boolean
suppressDuplicateTopicSubscriptionsxs:boolean
useBrokerNameAsIdSeesxs:boolean
useCompressionxs:boolean
userNamexs:string
ElementTypeDescription
bridgecompositeDemandForwardingBridge | demandForwardingBridge
brokerServicebroker | brokerService
connectionFilter<spring:bean/>
durableDestinations(<spring:bean/>)*
dynamicallyIncludedDestinations(<spring:bean/>)*
excludedDestinations(<spring:bean/>)*
localTransport<spring:bean/>
remoteTransport<spring:bean/>Sets the remote transport implementation
staticallyIncludedDestinations(<spring:bean/>)*

Element: multicastTraceBrokerPlugin

AttributeTypeDescription
broadcastxs:boolean
destinationxs:string
maxTraceDatagramSizexs:integer
timeToLivexs:integer
ElementTypeDescription
address<spring:bean/>
adminConnectionContext<spring:bean/>
nextdestinationPathSeparatorPlugin | forcePersistencyModeBroker | loggingBrokerPlugin | multicastTraceBrokerPlugin | redeliveryPlugin | timeStampingBrokerPlugin | traceBrokerPathPlugin | udpTraceBrokerPlugin
wireFormat<spring:bean/>
wireFormatFactory<spring:bean/>

Element: mysql-jdbc-adapter

AttributeTypeDescription
batchStatmentsxs:boolean
engineTypexs:string
maxRowsxs:integerthe max value for statement maxRows, used to limit jdbc queries
typeStatementxs:string
useExternalMessageReferencesxs:boolean
ElementTypeDescription
statementsstatements

Element: networkConnector

AttributeTypeDescription
advisoryForFailedForwardxs:boolean
alwaysSyncSendxs:boolean
bridgeTempDestinationsxs:boolean
brokerNamexs:string
brokerURLxs:string
conduitSubscriptionsxs:boolean
consumerPriorityBasexs:integer
consumerTTLxs:integer
decreaseNetworkConsumerPriorityxs:boolean
destinationFilterxs:string
discoveryURIxs:string
dispatchAsyncxs:boolean
duplexxs:boolean
dynamicOnlyxs:boolean
localUrixs:string
messageTTLxs:integer
namexs:string
networkTTLxs:integer
objectNamexs:string
passwordxs:string
prefetchSizexs:string
staticBridgexs:boolean
suppressDuplicateQueueSubscriptionsxs:boolean
suppressDuplicateTopicSubscriptionsxs:boolean
urixs:string
useBrokerNameAsIdSeesxs:boolean
useCompressionxs:boolean
userNamexs:string
ElementTypeDescription
brokerServicebroker | brokerService
connectionFilter<spring:bean/>
discoveryAgent<spring:bean/>
durableDestinations(<spring:bean/>)*
dynamicallyIncludedDestinations(<spring:bean/>)*
excludedDestinations(<spring:bean/>)*
staticallyIncludedDestinations(<spring:bean/>)*

Element: noSubscriptionRecoveryPolicy

ElementTypeDescription
brokerdestinationPathSeparatorPlugin | forcePersistencyModeBroker | loggingBrokerPlugin | multicastTraceBrokerPlugin | redeliveryPlugin | timeStampingBrokerPlugin | traceBrokerPathPlugin | udpTraceBrokerPlugin

Element: oldestMessageEvictionStrategy

AttributeTypeDescription
evictExpiredMessagesHighWatermarkxs:integerSets the high water mark on which we will eagerly evict expired messages from RAM

Element: oldestMessageWithLowestPriorityEvictionStrategy

AttributeTypeDescription
evictExpiredMessagesHighWatermarkxs:integerSets the high water mark on which we will eagerly evict expired messages from RAM

Element: oracleBlobJDBCAdapter

AttributeTypeDescription
batchStatmentsxs:boolean
maxRowsxs:integerthe max value for statement maxRows, used to limit jdbc queries
useExternalMessageReferencesxs:boolean
ElementTypeDescription
statementsstatements

Element: oracleJDBCAdapter

AttributeTypeDescription
batchStatmentsxs:boolean
maxRowsxs:integerthe max value for statement maxRows, used to limit jdbc queries
useExternalMessageReferencesxs:boolean
ElementTypeDescription
statementsstatements

Element: outboundQueueBridge

AttributeTypeDescription
doHandleReplyToxs:boolean
localQueueNamexs:string
outboundQueueNamexs:stringSets the name of the outbound queue name. If the inbound queue name has not been set already then this method uses the provided queue name to set the inbound topic name as well.
selectorxs:string
ElementTypeDescription
consumer<spring:bean/>
consumerConnection<spring:bean/>
consumerQueuequeue
jmsConnectorjmsQueueConnector | jmsTopicConnector
jmsMessageConvertorsimpleJmsMessageConvertor
producerConnection<spring:bean/>
producerQueuequeue

Element: outboundTopicBridge

AttributeTypeDescription
consumerNamexs:string
doHandleReplyToxs:boolean
localTopicNamexs:string
outboundTopicNamexs:stringSets the name of the outbound topic name. If the inbound topic name has not been set already then this method uses the provided topic name to set the inbound topic name as well.
selectorxs:string
ElementTypeDescription
consumer<spring:bean/>
consumerConnection<spring:bean/>
consumerTopictopic
jmsConnectorjmsQueueConnector | jmsTopicConnector
jmsMessageConvertorsimpleJmsMessageConvertor
producerConnection<spring:bean/>
producerTopictopic

Element: pListStoreImpl

AttributeTypeDescription
cleanupIntervalxs:long
directoryxs:string
enableIndexWriteAsyncxs:boolean
failIfDatabaseIsLockedxs:boolean
indexCacheSizexs:integer
indexEnablePageCachingxs:boolean
indexPageSizexs:integer
indexWriteBatchSizexs:integer
journalMaxFileLengthxs:integer
journalMaxWriteBatchSizexs:integer
lazyInitxs:boolean
ElementTypeDescription
brokerServicebroker | brokerService

Element: partitionBrokerPlugin

AttributeTypeDescription
configAsJsonxs:string
minTransferCountxs:integer
ElementTypeDescription
config<spring:bean/>

Element: policyEntry

AttributeTypeDescription
advisoryForConsumedxs:boolean
advisoryForDeliveryxs:boolean
advisoryForDiscardingMessagesxs:boolean
advisoryForFastProducersxs:boolean
advisoryForSlowConsumersxs:boolean
advisoryWhenFullxs:boolean
allConsumersExclusiveByDefaultxs:boolean
alwaysRetroactivexs:boolean
blockedProducerWarningIntervalxs:longSet's the interval at which warnings about producers being blocked by resource usage will be triggered. Values of 0 or less will disable warnings
consumersBeforeDispatchStartsxs:integer
cursorMemoryHighWaterMarkxs:integer
doOptimzeMessageStoragexs:boolean
durableTopicPrefetchxs:integerGet the durableTopicPrefetch
enableAuditxs:boolean
expireMessagesPeriodxs:long
gcInactiveDestinationsxs:boolean
gcWithNetworkConsumersxs:boolean
inactiveTimoutBeforeGCxs:long
lazyDispatchxs:boolean
maxAuditDepthxs:integer
maxBrowsePageSizexs:integer
maxExpirePageSizexs:integer
maxPageSizexs:integer
maxProducersToAuditxs:integer
maxQueueAuditDepthxs:integer
memoryLimitxs:stringWhen set using Xbean, values of the form "20 Mb", "1024kb", and "1g" can be used
messageGroupMapFactoryTypexs:string
minimumMessageSizexs:long
optimizeMessageStoreInFlightLimitxs:integer
optimizedDispatchxs:boolean
prioritizedMessagesxs:boolean
producerFlowControlxs:boolean
queuexs:stringA helper method to set the destination from a configuration file
queueBrowserPrefetchxs:integerGet the queueBrowserPrefetch
queuePrefetchxs:integerGet the queuePrefetch
reduceMemoryFootprintxs:boolean
sendAdvisoryIfNoConsumersxs:booleanSends an advisory message if a non-persistent message is sent and there are no active consumers
storeUsageHighWaterMarkxs:integer
strictOrderDispatchxs:boolean
tempQueuexs:boolean
tempTopicxs:boolean
timeBeforeDispatchStartsxs:integer
topicxs:stringA helper method to set the destination from a configuration file
topicPrefetchxs:integerGet the topicPrefetch
useCachexs:boolean
useConsumerPriorityxs:boolean
usePrefetchExtensionxs:boolean
ElementTypeDescription
deadLetterStrategydiscarding | individualDeadLetterStrategy | sharedDeadLetterStrategySets the policy used to determine which dead letter queue destination should be used
destinationqueue | tempQueue | tempTopic | topic
dispatchPolicypriorityDispatchPolicy | priorityNetworkDispatchPolicy | roundRobinDispatchPolicy | simpleDispatchPolicy | strictOrderDispatchPolicy
messageEvictionStrategyoldestMessageEvictionStrategy | oldestMessageWithLowestPriorityEvictionStrategy | uniquePropertyMessageEvictionStrategySets the eviction strategy used to decide which message to evict when the slow consumer needs to discard messages
messageGroupMapFactorycachedMessageGroupMapFactory | messageGroupHashBucketFactory | simpleMessageGroupMapFactorySets the factory used to create new instances of {MessageGroupMap} used to implement the Message Groups functionality.
networkBridgeFilterFactoryconditionalNetworkBridgeFilterFactory | defaultNetworkBridgeFilterFactory
pendingDurableSubscriberPolicyfileDurableSubscriberCursor | storeDurableSubscriberCursor | vmDurableCursor
pendingMessageLimitStrategyconstantPendingMessageLimitStrategy | prefetchRatePendingMessageLimitStrategySets the strategy to calculate the maximum number of messages that are allowed to be pending on consumers (in addition to their prefetch sizes). Once the limit is reached, non-durable topics can then start discarding old messages. This allows us to keep dispatching messages to slow consumers while not blocking fast consumers and discarding the messages oldest first.
pendingQueuePolicyfileQueueCursor | storeCursor | vmQueueCursor
pendingSubscriberPolicyfileCursor | vmCursor
slowConsumerStrategyabortSlowAckConsumerStrategy | abortSlowConsumerStrategy
subscriptionRecoveryPolicyfixedCountSubscriptionRecoveryPolicy | fixedSizedSubscriptionRecoveryPolicy | lastImageSubscriptionRecoveryPolicy | noSubscriptionRecoveryPolicy | queryBasedSubscriptionRecoveryPolicy | timedSubscriptionRecoveryPolicy

Element: policyMap

ElementTypeDescription
defaultEntrypolicyEntry
entries(<spring:bean/>)*A helper method to allow the destination map to be populated from a dependency injection framework such as Spring
policyEntries(<spring:bean/>)*Sets the individual entries on the policy map

Element: pooledConnectionFactory

AttributeTypeDescription
maxConnectionsxs:integer
maximumActivexs:integer
resourceNamexs:string
ElementTypeDescription
connectionFactoryconnectionFactory | xaConnectionFactory
transactionManager<spring:bean/>

Element: postgresql-jdbc-adapter

AttributeTypeDescription
acksPkNamexs:string
batchStatmentsxs:boolean
maxRowsxs:integerthe max value for statement maxRows, used to limit jdbc queries
useExternalMessageReferencesxs:boolean
ElementTypeDescription
statementsstatements

Element: prefetchPolicy

AttributeTypeDescription
allxs:integer
durableTopicPrefetchxs:integer
inputStreamPrefetchxs:integer
maximumPendingMessageLimitxs:integerSets how many messages a broker will keep around, above the prefetch limit, for non-durable topics before starting to discard older messages.
optimizeDurableTopicPrefetchxs:integer
queueBrowserPrefetchxs:integer
queuePrefetchxs:integer
topicPrefetchxs:integer

Element: prefetchRatePendingMessageLimitStrategy

AttributeTypeDescription
multiplierxs:doubleSets the multiplier of the prefetch size which will be used to define the maximum number of pending messages for non-durable topics before messages are discarded.

Element: priorityDispatchPolicy

Element: priorityNetworkDispatchPolicy

Element: proxyConnector

AttributeTypeDescription
bindxs:string
localUrixs:string
namexs:string
proxyToLocalBrokerxs:boolean
remotexs:string
ElementTypeDescription
server<spring:bean/>

Element: publishedAddressPolicy

AttributeTypeDescription
clusterClientUriQueryxs:stringGets the URI query that's configured on the published URI that's sent to client's when the cluster info is updated.
publishedHostStrategyxs:string
ElementTypeDescription
portMapping<spring:bean/>

Element: queryBasedSubscriptionRecoveryPolicy

ElementTypeDescription
brokerdestinationPathSeparatorPlugin | forcePersistencyModeBroker | loggingBrokerPlugin | multicastTraceBrokerPlugin | redeliveryPlugin | timeStampingBrokerPlugin | traceBrokerPathPlugin | udpTraceBrokerPlugin
query<spring:bean/>Sets the query strategy to load initial messages

Element: queue

AttributeTypeDescription
namexs:string
physicalNamexs:string
ElementTypeDescription
compositeDestinations(queue | tempQueue | tempTopic | topic)*
properties<spring:bean/>Get the properties from this instance for storing in JNDI

Element: queueDispatchSelector

ElementTypeDescription
destinationqueue | tempQueue | tempTopic | topic
exclusiveConsumer<spring:bean/>

Element: reconnectionPolicy

AttributeTypeDescription
backOffMultiplierxs:doubleGets the multiplier used to grow the delay between connection attempts from the initial time to the max set time. By default this value is set to 2.0.
initialReconnectDelayxs:longGets the initial delay value used before a reconnection attempt is made. If the use exponential back-off value is set to false then this will be the fixed time between connection attempts. By default this value is set to one second.
maxInitialConnectAttemptsxs:integerGets the maximum number of times that the {@link JmsConnector} will try to connect on startup to before it marks itself as failed and does not try any further connections.
maxReconnectAttemptsxs:integerGets the number of time that {@link JmsConnector} will attempt to connect or reconnect before giving up. By default the policy sets this value to a negative value meaning try forever.
maxSendRetriesxs:integerGets the maximum number of a times a Message send should be retried before a JMSExeception is thrown indicating that the operation failed.
maximumReconnectDelayxs:longGets the maximum delay that is inserted between each attempt to connect before another attempt is made. The default setting for this value is 30 seconds.
sendRetyDelayxs:longSet the amount of time the DestionationBridge will wait between attempts to forward a message. The default policy limits the minimum time between send attempt to one second.
useExponentialBackOffxs:booleanGets whether the policy uses the set back-off multiplier to grow the time between connection attempts.

Element: redeliveryPlugin

AttributeTypeDescription
fallbackToDeadLetterxs:booleanWhat to do if there is no matching redelivery policy for a destination. when true, the region broker DLQ processing will be used via sendToDeadLetterQueue when false, there is no action
sendToDlqIfMaxRetriesExceededxs:booleanWhat to do if the maxretries on a matching redelivery policy is exceeded. when true, the region broker DLQ processing will be used via sendToDeadLetterQueue when false, there is no action
ElementTypeDescription
adminConnectionContext<spring:bean/>
nextdestinationPathSeparatorPlugin | forcePersistencyModeBroker | loggingBrokerPlugin | multicastTraceBrokerPlugin | redeliveryPlugin | timeStampingBrokerPlugin | traceBrokerPathPlugin | udpTraceBrokerPlugin
redeliveryPolicyMapredeliveryPolicyMap

Element: redeliveryPolicy

AttributeTypeDescription
backOffMultiplierxs:double
collisionAvoidancePercentxs:short
initialRedeliveryDelayxs:long
maximumRedeliveriesxs:integer
maximumRedeliveryDelayxs:long
queuexs:stringA helper method to set the destination from a configuration file
redeliveryDelayxs:long
tempQueuexs:boolean
tempTopicxs:boolean
topicxs:stringA helper method to set the destination from a configuration file
useCollisionAvoidancexs:boolean
useExponentialBackOffxs:boolean
ElementTypeDescription
destinationqueue | tempQueue | tempTopic | topic

Element: redeliveryPolicyMap

ElementTypeDescription
defaultEntryredeliveryPolicy
entries(<spring:bean/>)*A helper method to allow the destination map to be populated from a dependency injection framework such as Spring
redeliveryPolicyEntries(<spring:bean/>)*Sets the individual entries on the redeliveryPolicyMap

Element: replicatedLevelDB

AttributeTypeDescription
asyncBufferSizexs:integer
bindxs:string
brokerNamexs:string
containerxs:string
directoryxs:string
failoverProducersAuditDepthxs:integer
flushDelayxs:integer
hostnamexs:string
indexBlockRestartIntervalxs:integer
indexBlockSizexs:integer
indexCacheSizexs:long
indexCompressionxs:string
indexFactoryxs:string
indexMaxOpenFilesxs:integer
indexWriteBufferSizexs:integer
lockKeepAlivePeriodxs:long
logCompressionxs:string
logSizexs:long
maxFailoverProducersToTrackxs:integer
monitorStatsxs:boolean
paranoidChecksxs:boolean
replicasxs:integer
securityTokenxs:string
syncxs:string
useLockxs:boolean
verifyChecksumsxs:boolean
weightxs:integer
zkAddressxs:string
zkPasswordxs:string
zkPathxs:string
zkSessionTmeoutxs:string
ElementTypeDescription
brokerServicebroker | brokerService
lockerdatabase-locker | lease-database-locker | shared-file-locker | transact-database-locker
usageManagersystemUsage

Element: roundRobinDispatchPolicy

Element: runtimeConfigurationPlugin

AttributeTypeDescription
checkPeriodxs:long

Element: shared-file-locker

AttributeTypeDescription
directoryxs:string
failIfLockedxs:boolean
lockAcquireSleepIntervalxs:long
namexs:string
ElementTypeDescription
lockablejdbcPersistenceAdapter | journalPersistenceAdapterFactory | journaledJDBC | kahaDB | levelDB | mKahaDB | replicatedLevelDB

Element: sharedDeadLetterStrategy

AttributeTypeDescription
enableAuditxs:boolean
processExpiredxs:boolean
processNonPersistentxs:boolean
ElementTypeDescription
deadLetterQueuequeue | tempQueue | tempTopic | topic

Element: simpleAuthenticationPlugin

AttributeTypeDescription
anonymousAccessAllowedxs:boolean
anonymousGroupxs:string
anonymousUserxs:string
ElementTypeDescription
userGroups<spring:bean/>Sets the groups a user is in. The key is the user name and the value is a Set of groups
userPasswords<spring:bean/>Sets the map indexed by user name with the value the password
users(<spring:bean/>)*Sets individual users for authentication

Element: simpleAuthorizationMap

ElementTypeDescription
adminACLsauthorizationMap | policyMap | redeliveryPolicyMap
readACLsauthorizationMap | policyMap | redeliveryPolicyMap
tempDestinationAuthorizationEntrytempDestinationAuthorizationEntry
writeACLsauthorizationMap | policyMap | redeliveryPolicyMap

Element: simpleDispatchPolicy

Element: simpleDispatchSelector

ElementTypeDescription
destinationqueue | tempQueue | tempTopic | topic

Element: simpleJmsMessageConvertor

ElementTypeDescription
connection<spring:bean/>

Element: simpleMessageGroupMapFactory

Element: sslContext

AttributeTypeDescription
keyStorexs:string
keyStoreAlgorithmxs:string
keyStoreKeyPasswordxs:string
keyStorePasswordxs:string
keyStoreTypexs:string
protocolxs:string
providerxs:string
secureRandomAlgorithmxs:string
trustStorexs:string
trustStoreAlgorithmxs:string
trustStorePasswordxs:string
trustStoreTypexs:string
ElementTypeDescription
SSLContext<spring:bean/>
keyManagers(<spring:bean/>)*
secureRandom<spring:bean/>
trustManagers(<spring:bean/>)*

Element: statements

AttributeTypeDescription
addMessageStatementxs:string
binaryDataTypexs:string
clearDurableLastAckInTxStatementxs:string
clearXidFlagStatementxs:string
containerNameDataTypexs:string
createDurableSubStatementxs:string
currentDateTimeStatementxs:string
deleteOldMessagesStatementWithPriorityxs:string
deleteSubscriptionStatementxs:string
destinationMessageCountStatementxs:string
dropAckPKAlterStatementEndxs:string
durableSubAcksTableNamexs:string
durableSubscriberMessageCountStatementxs:string
durableSubscriberMessageCountStatementWithPriorityxs:string
findAcksPendingOutcomeStatementxs:string
findAllDestinationsStatementxs:string
findAllDurableSubMessagesStatementxs:string
findAllDurableSubsStatementxs:string
findAllMessagesStatementxs:string
findDurableSubMessagesStatementxs:string
findDurableSubStatementxs:string
findLastSequenceIdInAcksStatementxs:string
findLastSequenceIdInMsgsStatementxs:string
findMessageByIdStatementxs:string
findMessageSequenceIdStatementxs:string
findMessageStatementxs:string
findNextMessagesStatementxs:string
findOpsPendingOutcomeStatementxs:string
findXidByIdStatementxs:string
insertDurablePriorityAckStatementxs:string
lastAckedDurableSubscriberMessageStatementxs:string
lastProducerSequenceIdStatementxs:string
leaseObtainStatementxs:string
leaseOwnerStatementxs:string
leaseUpdateStatementxs:string
lockCreateStatementxs:string
lockTableNamexs:string
lockUpdateStatementxs:string
longDataTypexs:string
messageTableNamexs:string
msgIdDataTypexs:string
nextDurableSubscriberMessageStatementxs:string
removeAllMessagesStatementxs:string
removeAllSubscriptionsStatementxs:string
removeMessageStatmentxs:string
selectDurablePriorityAckStatementxs:string
sequenceDataTypexs:string
stringIdDataTypexs:string
tablePrefixxs:string
updateDurableLastAckInTxStatementxs:string
updateDurableLastAckStatementxs:string
updateDurableLastAckWithPriorityInTxStatementxs:string
updateDurableLastAckWithPriorityStatementxs:string
updateLastPriorityAckRowOfDurableSubStatementxs:string
updateMessageStatementxs:string
updateXidFlagStatementxs:string
useExternalMessageReferencesxs:boolean
useLockCreateWhereClausexs:boolean
ElementTypeDescription
createLockSchemaStatements(<spring:bean/>)*
createSchemaStatements(<spring:bean/>)*
dropSchemaStatements(<spring:bean/>)*

Element: statisticsBrokerPlugin

Element: storeCursor

Element: storeDurableSubscriberCursor

AttributeTypeDescription
immediatePriorityDispatchxs:booleanEnsure that new higher priority messages will get an immediate dispatch rather than wait for the end of the current cursor batch. Useful when there is a large message backlog and intermittent high priority messages.
useCachexs:boolean

Element: storeUsage

AttributeTypeDescription
limitxs:stringSets the memory limit in bytes. Setting the limit in bytes will set the usagePortion to 0 since the UsageManager is not going to be portion based off the parent. When set using Xbean, values of the form "20 Mb", "1024kb", and "1g" can be used
namexs:string
percentUsagexs:integer
percentUsageMinDeltaxs:stringSets the minimum number of percentage points the usage has to change before a UsageListener event is fired by the manager.
pollingTimexs:integer
usagePortionxs:float
ElementTypeDescription
executor<spring:bean/>
limiterdefaultUsageCapacity | usageCapacity
parent<spring:bean/>
storejdbcPersistenceAdapter | journalPersistenceAdapter | kahaDB | levelDB | mKahaDB | memoryPersistenceAdapter | replicatedLevelDB

Element: streamJDBCAdapter

AttributeTypeDescription
batchStatmentsxs:boolean
maxRowsxs:integerthe max value for statement maxRows, used to limit jdbc queries
useExternalMessageReferencesxs:boolean
ElementTypeDescription
statementsstatements

Element: strictOrderDispatchPolicy

Element: sybase-jdbc-adapter

AttributeTypeDescription
batchStatmentsxs:boolean
maxRowsxs:integerthe max value for statement maxRows, used to limit jdbc queries
useExternalMessageReferencesxs:boolean
ElementTypeDescription
statementsstatements

Element: systemUsage

AttributeTypeDescription
namexs:string
sendFailIfNoSpacexs:booleanSets whether or not a send() should fail if there is no space free. The default value is false which means to block the send() method until space becomes available
sendFailIfNoSpaceAfterTimeoutxs:long
sendFailIfNoSpaceExplicitySetxs:boolean
ElementTypeDescription
adapterjdbcPersistenceAdapter | journalPersistenceAdapter | kahaDB | levelDB | mKahaDB | memoryPersistenceAdapter | replicatedLevelDB
executor<spring:bean/>
jobSchedulerStore<spring:bean/>
jobSchedulerUsagejobSchedulerUsage
memoryUsagememoryUsage
parentsystemUsage
storeUsagestoreUsage
tempStorelevelDB | pListStoreImpl | replicatedLevelDB
tempUsagetempUsage

Element: taskRunnerFactory

AttributeTypeDescription
daemonxs:boolean
dedicatedTaskRunnerxs:boolean
maxIterationsPerRunxs:integer
maxThreadPoolSizexs:integer
namexs:string
priorityxs:integer
shutdownAwaitTerminationxs:long
ElementTypeDescription
executor<spring:bean/>
rejectedTaskHandler<spring:bean/>

Element: tempDestinationAuthorizationEntry

AttributeTypeDescription
adminxs:string
groupClassxs:string
queuexs:stringA helper method to set the destination from a configuration file
readxs:string
tempQueuexs:boolean
tempTopicxs:boolean
topicxs:stringA helper method to set the destination from a configuration file
writexs:string
ElementTypeDescription
adminACLs(<spring:bean/>)*
destinationqueue | tempQueue | tempTopic | topic
readACLs(<spring:bean/>)*
writeACLs(<spring:bean/>)*

Element: tempQueue

AttributeTypeDescription
connectionIdxs:string
namexs:string
physicalNamexs:string
sequenceIdxs:long
ElementTypeDescription
compositeDestinations(queue | tempQueue | tempTopic | topic)*
connection<spring:bean/>
properties<spring:bean/>Get the properties from this instance for storing in JNDI

Element: tempTopic

AttributeTypeDescription
connectionIdxs:string
namexs:string
physicalNamexs:string
sequenceIdxs:long
ElementTypeDescription
compositeDestinations(queue | tempQueue | tempTopic | topic)*
connection<spring:bean/>
properties<spring:bean/>Get the properties from this instance for storing in JNDI

Element: tempUsage

AttributeTypeDescription
limitxs:stringSets the memory limit in bytes. Setting the limit in bytes will set the usagePortion to 0 since the UsageManager is not going to be portion based off the parent. When set using Xbean, values of the form "20 Mb", "1024kb", and "1g" can be used
namexs:string
percentUsagexs:integer
percentUsageMinDeltaxs:stringSets the minimum number of percentage points the usage has to change before a UsageListener event is fired by the manager.
pollingTimexs:integer
usagePortionxs:float
ElementTypeDescription
executor<spring:bean/>
limiterdefaultUsageCapacity | usageCapacity
parent<spring:bean/>
storelevelDB | pListStoreImpl | replicatedLevelDB

Element: timeStampingBrokerPlugin

AttributeTypeDescription
futureOnlyxs:boolean
ttlCeilingxs:longsetter method for ttlCeiling
zeroExpirationOverridexs:longsetter method for zeroExpirationOverride
ElementTypeDescription
adminConnectionContext<spring:bean/>
nextdestinationPathSeparatorPlugin | forcePersistencyModeBroker | loggingBrokerPlugin | multicastTraceBrokerPlugin | redeliveryPlugin | timeStampingBrokerPlugin | traceBrokerPathPlugin | udpTraceBrokerPlugin
processNetworkMessages<spring:bean/>

Element: timedSubscriptionRecoveryPolicy

AttributeTypeDescription
recoverDurationxs:long
ElementTypeDescription
brokerdestinationPathSeparatorPlugin | forcePersistencyModeBroker | loggingBrokerPlugin | multicastTraceBrokerPlugin | redeliveryPlugin | timeStampingBrokerPlugin | traceBrokerPathPlugin | udpTraceBrokerPlugin

Element: topic

AttributeTypeDescription
namexs:string
physicalNamexs:string
ElementTypeDescription
compositeDestinations(queue | tempQueue | tempTopic | topic)*
properties<spring:bean/>Get the properties from this instance for storing in JNDI

Element: traceBrokerPathPlugin

AttributeTypeDescription
stampPropertyxs:string
ElementTypeDescription
adminConnectionContext<spring:bean/>
nextdestinationPathSeparatorPlugin | forcePersistencyModeBroker | loggingBrokerPlugin | multicastTraceBrokerPlugin | redeliveryPlugin | timeStampingBrokerPlugin | traceBrokerPathPlugin | udpTraceBrokerPlugin

Element: transact-database-locker

AttributeTypeDescription
createTablesOnStartupxs:boolean
failIfLockedxs:boolean
lockAcquireSleepIntervalxs:long
namexs:string
queryTimeoutxs:integer
ElementTypeDescription
dataSource<spring:bean/>
exceptionHandler<spring:bean/>
lockablejdbcPersistenceAdapter | journalPersistenceAdapterFactory | journaledJDBC | kahaDB | levelDB | mKahaDB | replicatedLevelDB
statementsstatements

Element: transact-jdbc-adapter

AttributeTypeDescription
batchStatmentsxs:boolean
maxRowsxs:integerthe max value for statement maxRows, used to limit jdbc queries
useExternalMessageReferencesxs:boolean
ElementTypeDescription
statementsstatements

Element: transportConnector

AttributeTypeDescription
allowLinkStealingxs:boolean
auditNetworkProducersxs:booleanEnable a producer audit on network connections, Traps the case of a missing send reply and resend. Note: does not work with conduit=false, networked composite destinations or networked virtual topics
disableAsyncDispatchxs:boolean
discoveryUrixs:string
enableStatusMonitorxs:boolean
maximumConsumersAllowedPerConnectionxs:integer
maximumProducersAllowedPerConnectionxs:integer
namexs:string
rebalanceClusterClientsxs:boolean
updateClusterClientsxs:boolean
updateClusterClientsOnRemovexs:boolean
updateClusterFilterxs:string
urixs:stringSets the server transport URI to use if there is not a {@link TransportServer} configured via the {@link #setServer(TransportServer)} method. This value is used to lazy create a {@link TransportServer} instance
ElementTypeDescription
brokerInfo<spring:bean/>
brokerServicebroker | brokerServiceThis is called by the BrokerService right before it starts the transport.
discoveryAgent<spring:bean/>
messageAuthorizationPolicy<spring:bean/>Sets the policy used to decide if the current connection is authorized to consume a given message
publishedAddressPolicypublishedAddressPolicyGets the currently configured policy for creating the published connection address of this TransportConnector.
server<spring:bean/>
taskRunnerFactorytaskRunnerFactory

Element: udpTraceBrokerPlugin

AttributeTypeDescription
broadcastxs:boolean
destinationxs:string
maxTraceDatagramSizexs:integer
ElementTypeDescription
address<spring:bean/>
adminConnectionContext<spring:bean/>
nextdestinationPathSeparatorPlugin | forcePersistencyModeBroker | loggingBrokerPlugin | multicastTraceBrokerPlugin | redeliveryPlugin | timeStampingBrokerPlugin | traceBrokerPathPlugin | udpTraceBrokerPlugin
wireFormat<spring:bean/>
wireFormatFactory<spring:bean/>

Element: uniquePropertyMessageEvictionStrategy

AttributeTypeDescription
evictExpiredMessagesHighWatermarkxs:integerSets the high water mark on which we will eagerly evict expired messages from RAM
propertyNamexs:string

Element: usageCapacity

AttributeTypeDescription
limitxs:long

Element: virtualDestinationInterceptor

ElementTypeDescription
virtualDestinations(compositeQueue | compositeTopic | virtualTopic)*

Element: virtualSelectorCacheBrokerPlugin

AttributeTypeDescription
persistFilexs:stringSets the location of the persistent cache

Element: virtualTopic

AttributeTypeDescription
localxs:boolean
namexs:string
postfixxs:stringSets any postix used to identify the queue consumers
prefixxs:stringSets the prefix wildcard used to identify the queue consumers for a given topic
selectorAwarexs:booleanIndicates whether the selectors of consumers are used to determine dispatch to a virtual destination, when true only messages matching an existing consumer will be dispatched.

Element: vmCursor

Element: vmDurableCursor

Element: vmQueueCursor

Element: xaConnectionFactory

AttributeTypeDescription
alwaysSessionAsyncxs:booleanIf this flag is not set then a separate thread is not used for dispatching messages for each Session in the Connection. However, a separate thread is always used if there is more than one session, or the session isn't in auto acknowledge or duplicates ok mode. By default this value is set to true and session dispatch happens asynchronously.
alwaysSyncSendxs:booleanSet true if always require messages to be sync sent
auditDepthxs:integer
auditMaximumProducerNumberxs:integer
beanNamexs:string
brokerURLxs:stringSets the connection URL used to connect to the ActiveMQ broker.
checkForDuplicatesxs:boolean
clientIDxs:stringSets the JMS clientID to use for the created connection. Note that this can only be used by one connection at once so generally its a better idea to set the clientID on a Connection
clientIDPrefixxs:stringSets the prefix used by autogenerated JMS Client ID values which are used if the JMS client does not explicitly specify on.
closeTimeoutxs:integerSets the timeout before a close is considered complete. Normally a close() on a connection waits for confirmation from the broker; this allows that operation to timeout to save the client hanging if there is no broker
connectionIDPrefixxs:stringSets the prefix used by connection id generator
consumerFailoverRedeliveryWaitPeriodxs:long
copyMessageOnSendxs:booleanShould a JMS message be copied to a new JMS Message object as part of the send() method in JMS. This is enabled by default to be compliant with the JMS specification. You can disable it if you do not mutate JMS messages after they are sent for a performance boost
disableTimeStampsByDefaultxs:booleanSets whether or not timestamps on messages should be disabled or not. If you disable them it adds a small performance boost.
dispatchAsyncxs:booleanEnables or disables the default setting of whether or not consumers have their messages dispatched synchronously or asynchronously by the broker. For non-durable topics for example we typically dispatch synchronously by default to minimize context switches which boost performance. However sometimes its better to go slower to ensure that a single blocked consumer socket does not block delivery to other consumers.
exclusiveConsumerxs:booleanEnables or disables whether or not queue consumers should be exclusive or not for example to preserve ordering when not using Message Groups
maxThreadPoolSizexs:integer
messagePrioritySupportedxs:boolean
nestedMapAndListEnabledxs:booleanEnables/disables whether or not Message properties and MapMessage entries support Nested Structures of Map and List objects
nonBlockingRedeliveryxs:booleanWhen true a MessageConsumer will not stop Message delivery before re-delivering Messages from a rolled back transaction. This implies that message order will not be preserved and also will result in the TransactedIndividualAck option to be enabled.
objectMessageSerializationDeferedxs:booleanWhen an object is set on an ObjectMessage, the JMS spec requires the object to be serialized by that set method. Enabling this flag causes the object to not get serialized. The object may subsequently get serialized if the message needs to be sent over a socket or stored to disk.
optimizeAcknowledgexs:boolean
optimizeAcknowledgeTimeOutxs:longThe max time in milliseconds between optimized ack batches
optimizedAckScheduledAckIntervalxs:longGets the configured time interval that is used to force all MessageConsumers that have optimizedAcknowledge enabled to send an ack for any outstanding Message Acks. By default this value is set to zero meaning that the consumers will not do any background Message acknowledgment.
optimizedMessageDispatchxs:booleanIf this flag is set then an larger prefetch limit is used - only applicable for durable topic subscribers.
passwordxs:stringSets the JMS password used for connections created from this factory
producerWindowSizexs:integer
sendAcksAsyncxs:boolean
sendTimeoutxs:integer
statsEnabledxs:boolean
transactedIndividualAckxs:booleanwhen true, submit individual transacted acks immediately rather than with transaction completion. This allows the acks to represent delivery status which can be persisted on rollback Used in conjunction with org.apache.activemq.store.kahadb.KahaDBPersistenceAdapter#setRewriteOnRedelivery(boolean) true
useAsyncSendxs:booleanForces the use of Async Sends which adds a massive performance boost; but means that the send() method will return immediately whether the message has been sent or not which could lead to message loss.
useBeanNameAsClientIdPrefixxs:boolean
useCompressionxs:booleanEnables the use of compression of the message bodies
useDedicatedTaskRunnerxs:boolean
useRetroactiveConsumerxs:booleanSets whether or not retroactive consumers are enabled. Retroactive consumers allow non-durable topic subscribers to receive old messages that were published before the non-durable subscriber started.
userNamexs:stringSets the JMS userName used by connections created by this factory
warnAboutUnstartedConnectionTimeoutxs:longEnables the timeout from a connection creation to when a warning is generated if the connection is not properly started via {@link Connection#start()} and a message is received by a consumer. It is a very common gotcha to forget to start the connection so this option makes the default case to create a warning if the user forgets. To disable the warning just set the value to < 0 (say -1).
watchTopicAdvisoriesxs:boolean
xaAckModexs:integer
ElementTypeDescription
blobTransferPolicy<spring:bean/>Sets the policy used to describe how out-of-band BLOBs (Binary Large OBjects) are transferred from producers to brokers to consumers
clientIdGenerator<spring:bean/>
clientInternalExceptionListener<spring:bean/>Allows an {@link ClientInternalExceptionListener} to be configured on the ConnectionFactory so that when this factory is used by frameworks which don't expose the Connection such as Spring JmsTemplate, you can register an exception listener.

Note: access to this clientInternalExceptionListener will not be serialized if it is associated with more than on connection (as it will be if more than one connection is subsequently created by this connection factory)

connectionIdGenerator<spring:bean/>
exceptionListener<spring:bean/>Allows an {@link ExceptionListener} to be configured on the ConnectionFactory so that when this factory is used by frameworks which don't expose the Connection such as Spring JmsTemplate, you can register an exception listener.

Note: access to this exceptionLinstener will not be serialized if it is associated with more than on connection (as it will be if more than one connection is subsequently created by this connection factory)

prefetchPolicyprefetchPolicySets the prefetch policy for consumers created by this connection.
properties<spring:bean/>Get the properties from this instance for storing in JNDI
redeliveryPolicyredeliveryPolicySets the global default redelivery policy to be used when a message is delivered but the session is rolled back
redeliveryPolicyMapredeliveryPolicyMapSets the global redelivery policy mapping to be used when a message is delivered but the session is rolled back
rejectedTaskHandler<spring:bean/>
sessionTaskRunnertaskRunnerFactory
transformer<spring:bean/>Sets the transformer used to transform messages before they are sent on to the JMS bus or when they are received from the bus but before they are delivered to the JMS client
transportListener<spring:bean/>Allows a listener to be configured on the ConnectionFactory so that when this factory is used with frameworks which don't expose the Connection such as Spring JmsTemplate, you can still register a transport listener.