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
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.AuthorizationEntry
authorizationMapRepresents a destination based configuration of policies so that individual destinations or wildcard hierarchies of destinations can be configured using different policies. Each entry in the map represents the authorization ACLs for each operation.org.apache.activemq.security.DefaultAuthorizationMap
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
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
commandAgentAn agent which listens to commands on a JMS destinationorg.apache.activemq.broker.util.CommandAgent
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
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
db2JDBCAdapterorg.apache.activemq.store.jdbc.adapter.DB2JDBCAdapter
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
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
fileDurableSubscriberCursorPending messages for durable subscribersorg.apache.activemq.broker.region.policy.FilePendingDurableSubscriberMessageStoragePolicy
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
forwardingBridgeForwards all messages from the local broker to the remote broker.org.apache.activemq.network.ForwardingBridge
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 Bridgeorg.apache.activemq.network.jms.InboundQueueBridge
inboundTopicBridgeCreate an Inbound Topic Bridgeorg.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
jaasAuthenticationPluginProvides a JAAS based authentication pluginorg.apache.activemq.security.JaasAuthenticationPlugin
jaasCertificateAuthenticationPluginProvides a JAAS based SSL certificate authentication pluginorg.apache.activemq.security.JaasCertificateAuthenticationPlugin
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
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
journaledJDBCCreates a default persistence model using the Journal and JDBCorg.apache.activemq.store.PersistenceAdapterFactoryBean
kahaPersistenceAdapterorg.apache.activemq.store.kahadaptor.KahaPersistenceAdapter
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
loggingBrokerPluginA simple Broker interceptor which allows you to enable/disable logging.org.apache.activemq.broker.util.LoggingBrokerPlugin
managementContextA Flow provides different dispatch policies within the NMRorg.apache.activemq.broker.jmx.ManagementContext
masterConnectorConnects a Slave Broker to a Master when using Master Slave for High Availability of messages.org.apache.activemq.broker.ft.MasterConnector
memoryPersistenceAdapterorg.apache.activemq.store.memory.MemoryPersistenceAdapter
messageGroupHashBucketFactoryA factory to create instances of {@link SimpleMessageGroupMap} when implementing the Message Groups functionality.org.apache.activemq.broker.region.group.MessageGroupHashBucketFactory
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
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
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.

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.OracleJDBCAdapter
outboundQueueBridgeCreate an Outbound Queue Bridgeorg.apache.activemq.network.jms.OutboundQueueBridge
outboundTopicBridgeCreate an Outbound Topic Bridgeorg.apache.activemq.network.jms.OutboundTopicBridge
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
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
proxyConnectororg.apache.activemq.proxy.ProxyConnector
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 Queue Destinationorg.apache.activemq.command.ActiveMQQueue
quickJournalPersistenceAdapterAn 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.QuickJournalPersistenceAdapter
rapidPersistenceAdapterAn 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.rapid.RapidPersistenceAdapter
redeliveryPolicyConfiguration options used to control how messages are re-delivered when they are rolled back.org.apache.activemq.RedeliveryPolicy
roundRobinDispatchPolicySimple dispatch policy that sends a message to every subscription that matches the message.org.apache.activemq.broker.region.policy.RoundRobinDispatchPolicy
sharedDeadLetterStrategyA default implementation of {@link DeadLetterStrategy} which uses a constant destination.org.apache.activemq.broker.region.policy.SharedDeadLetterStrategy
simpleAuthenticationPluginProvides a simple authenticationorg.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
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
statementsorg.apache.activemq.store.jdbc.Statements
storeDurableSubscriberCursorPending messages for a durable subscriberorg.apache.activemq.broker.region.policy.StorePendingDurableSubscriberMessageStoragePolicy
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
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 Topic Destinationorg.apache.activemq.command.ActiveMQTopic
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
usageManagerUsed 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.memory.UsageManager
virtualDestinationInterceptorImplements Virtual Topics.org.apache.activemq.broker.region.virtual.VirtualDestinationInterceptor
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 held in the JVMorg.apache.activemq.broker.region.policy.VMPendingDurableSubscriberMessageStoragePolicy
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: authorizationEntry

AttributeTypeDescription
adminxs:string
queuexs:stringA helper method to set the destination from a configuration file
readxs:string
topicxs:stringA helper method to set the destination from a configuration file
writexs:string
ElementTypeDescription
adminACLs<spring:bean/>
destinationqueue | topic
readACLs<spring:bean/>
writeACLs<spring:bean/>

Element: authorizationMap

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

Element: authorizationPlugin

ElementTypeDescription
mapauthorizationMap | lDAPAuthorizationMap | simpleAuthorizationMap

Element: axionJDBCAdapter

AttributeTypeDescription
batchStatmentsxs:boolean
useExternalMessageReferencesxs:boolean
ElementTypeDescription
statementsstatements

Element: blobJDBCAdapter

AttributeTypeDescription
batchStatmentsxs:boolean
useExternalMessageReferencesxs:boolean
ElementTypeDescription
statementsstatements

Element: broker

AttributeTypeDescription
advisorySupportxs:booleanAllows the support of advisory messages to be disabled for performance reasons.
brokerNamexs:stringSets the name of this broker; which must be unique in the network
brokerObjectNamexs:stringSets the JMX ObjectName for this broker
dataDirectoryxs:stringSets the directory in which the data files will be stored by default for the JDBC and Journal persistence adaptors.
deleteAllMessagesOnStartupxs:booleanSets whether or not all messages are deleted on startup - mostly only useful for testing.
keepDurableSubsActivexs:boolean
masterConnectorURIxs:string
persistenceThreadPriorityxs:integer
persistentxs:booleanSets whether or not persistence is enabled or disabled.
populateJMSXUserIDxs:booleanSets whether or not the broker should populate the JMSXUserID header.
shutdownOnMasterFailurexs: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.
tmpDataDirectoryxs:string
useJmxxs:booleanSets whether or not the Broker's services should be exposed into JMX or not.
useLoggingForShutdownErrorsxs:booleanSets whether or not we should use commons-logging when reporting errors when shutting down the broker
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.
useVirtualTopicsxs:booleanSets whether or not Virtual Topics should be supported by default if they have not been explicitly configured.
vmConnectorURIxs:string
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.
destinationFactory<spring:bean/>
destinationInterceptors(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 | topic)*Sets the destinations which should be loaded/created on startup
jmsBridgeConnectors(jmsQueueConnector | jmsTopicConnector)*
managementContextmanagementContext
memoryManagerusageManager
messageAuthorizationPolicy<spring:bean/>Sets the policy used to decide if the current connection is authorized to consume a given message
networkConnectorURIs(<spring:bean/>)*
networkConnectors(multicastNetworkConnector | networkConnector)*Sets the network connectors which this broker will use to connect to other brokers in a federated network
pendingDurableSubscriberPolicyfileDurableSubscriberCursor | storeDurableSubscriberCursor | vmCursor
persistenceAdapterjdbcPersistenceAdapter | journalPersistenceAdapter | kahaPersistenceAdapter | memoryPersistenceAdapter | quickJournalPersistenceAdapter | rapidPersistenceAdapterSets the persistence adaptor implementation to use for this broker
persistenceFactoryjournaledJDBC
persistenceTaskRunnerFactory<spring:bean/>
plugins(authorizationPlugin | connectionDotFilePlugin | destinationDotFilePlugin | jaasAuthenticationPlugin | jaasCertificateAuthenticationPlugin | loggingBrokerPlugin | multicastTraceBrokerPlugin | simpleAuthenticationPlugin | udpTraceBrokerPlugin)*Sets a number of broker plugins to install such as for security authentication or authorization
proxyConnectors(<spring:bean/>)*Sets the network connectors which this broker will use to connect to other brokers in a federated network
services(broker | commandAgent | inboundQueueBridge | inboundTopicBridge | jmsQueueConnector | jmsTopicConnector | managementContext | masterConnector | multicastNetworkConnector | networkConnector | outboundQueueBridge | outboundTopicBridge | proxyConnector)*Sets the services associated with this broker such as a {@link MasterConnector}
taskRunnerFactory<spring:bean/>
tempDataStore<spring:bean/>
transportConnectorURIs(<spring:bean/>)*
transportConnectors(transportConnector)*Sets the transport connectors which this broker will listen on for new clients

Element: bytesJDBCAdapter

AttributeTypeDescription
batchStatmentsxs:boolean
useExternalMessageReferencesxs:boolean
ElementTypeDescription
statementsstatements

Element: commandAgent

AttributeTypeDescription
brokerUrlxs:string
ElementTypeDescription
brokerServicebroker
commandDestinationqueue | topic
connection<spring:bean/>
connectionFactory<spring:bean/>

Element: compositeDemandForwardingBridge

AttributeTypeDescription
bridgeTempDestinationsxs:boolean
decreaseNetworkConsumerPriorityxs:boolean
dispatchAsyncxs:boolean
localBrokerNamexs:string
namexs:string
networkTTLxs:integer
passwordxs:string
prefetchSizexs:integer
userNamexs:string
ElementTypeDescription
durableDestinations(queue | topic)*
dynamicallyIncludedDestinations(queue | topic)*
excludedDestinations(queue | topic)*
localBroker<spring:bean/>
remoteBroker<spring:bean/>
staticallyIncludedDestinations(queue | 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: connectionDotFilePlugin

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

Element: connectionFactory

AttributeTypeDescription
alwaysSessionAsyncxs:booleanIf this flag is 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
beanNamexs:string
brokerURLxs:stringSets the connection URL used to connect to the ActiveMQ broker.
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
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.
nestedMapAndListEnabledxs:booleanEnables/disables whether or not Message properties and MapMessage entries support Nested Structures of Map and List objects
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
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
statsEnabledxs:boolean
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
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
ElementTypeDescription
clientIdGenerator<spring:bean/>
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 redelivery policy to be used when a message is delivered but the session is rolled back

Element: constantPendingMessageLimitStrategy

AttributeTypeDescription
limitxs:integer

Element: db2JDBCAdapter

AttributeTypeDescription
batchStatmentsxs:boolean
useExternalMessageReferencesxs:boolean
ElementTypeDescription
statementsstatements

Element: defaultJDBCAdapter

AttributeTypeDescription
batchStatmentsxs:boolean
useExternalMessageReferencesxs:boolean
ElementTypeDescription
statementsstatements

Element: demandForwardingBridge

AttributeTypeDescription
bridgeTempDestinationsxs:boolean
decreaseNetworkConsumerPriorityxs:boolean
dispatchAsyncxs:boolean
localBrokerNamexs:string
namexs:string
networkTTLxs:integer
passwordxs:string
prefetchSizexs:integer
userNamexs:string
ElementTypeDescription
durableDestinations(queue | topic)*
dynamicallyIncludedDestinations(queue | topic)*
excludedDestinations(queue | topic)*
localBroker<spring:bean/>
remoteBroker<spring:bean/>
staticallyIncludedDestinations(queue | 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
topicxs:stringA helper method to set the destination from a configuration file
ElementTypeDescription
destinationqueue | topic
value<spring:bean/>

Element: fileDurableSubscriberCursor

Element: fixedCountSubscriptionRecoveryPolicy

AttributeTypeDescription
maximumSizexs:integerSets the maximum number of messages that this destination will hold around in RAM

Element: fixedSizedSubscriptionRecoveryPolicy

AttributeTypeDescription
maximumSizexs:integerSets the maximum amount of RAM in bytes that this buffer can hold in RAM
useSharedBufferxs:boolean
ElementTypeDescription
buffer<spring:bean/>

Element: forwardingBridge

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

Element: imageBasedJDBCAdaptor

AttributeTypeDescription
batchStatmentsxs:boolean
useExternalMessageReferencesxs:boolean
ElementTypeDescription
statementsstatements

Element: inboundQueueBridge

AttributeTypeDescription
doHandleReplyToxs:boolean
inboundQueueNamexs:string
localQueueNamexs:string
maximumRetriesxs:integerSets the maximum number of retries if a send fails before closing the bridge
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:string
localTopicNamexs:string
maximumRetriesxs:integerSets the maximum number of retries if a send fails before closing the bridge
selectorxs:string
ElementTypeDescription
consumer<spring:bean/>
consumerConnection<spring:bean/>
consumerTopictopic
jmsConnectorjmsQueueConnector | jmsTopicConnector
jmsMessageConvertorsimpleJmsMessageConvertor
producerConnection<spring:bean/>
producerTopictopic

Element: individualDeadLetterStrategy

AttributeTypeDescription
queuePrefixxs:stringSets the prefix to use for all dead letter queues for queue messages
topicPrefixxs:stringSets the prefix 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
useExternalMessageReferencesxs:boolean
ElementTypeDescription
statementsstatements

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: jdbcPersistenceAdapter

AttributeTypeDescription
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
useDatabaseLockxs:booleanSets whether or not an exclusive database lock should be used to enable JDBC Master/Slave. Enabled by default.
useExternalMessageReferencesxs:boolean
ElementTypeDescription
adapteraxionJDBCAdapter | blobJDBCAdapter | bytesJDBCAdapter | db2JDBCAdapter | defaultJDBCAdapter | imageBasedJDBCAdaptor | informixJDBCAdapter | oracleJDBCAdapter | streamJDBCAdapter
brokerServicebroker
dataSource<spring:bean/>
databaseLocker<spring:bean/>Sets the database locker strategy to use to lock the database on startup
ds<spring:bean/>
scheduledThreadPoolExecutor<spring:bean/>
statementsstatements
usageManagerusageManager
wireFormat<spring:bean/>

Element: jmsQueueConnector

AttributeTypeDescription
jndiLocalTemplatexs:string
jndiOutboundTemplatexs:string
localConnectionFactoryNamexs:string
localPasswordxs:string
localUsernamexs:string
namexs:string
outboundPasswordxs:string
outboundQueueConnectionFactoryNamexs:string
outboundUsernamexs:string
replyToDestinationCacheSizexs:integer
ElementTypeDescription
brokerServicebrokerOne 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

Element: jmsTopicConnector

AttributeTypeDescription
jndiLocalTemplatexs:string
jndiOutboundTemplatexs:string
localConnectionFactoryNamexs:string
localPasswordxs:string
localUsernamexs:string
namexs:string
outboundPasswordxs:string
outboundTopicConnectionFactoryNamexs:string
outboundUsernamexs:string
replyToDestinationCacheSizexs:integer
ElementTypeDescription
brokerServicebrokerOne 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

Element: journalPersistenceAdapter

AttributeTypeDescription
maxCheckpointMessageAddSizexs:integer
maxCheckpointWorkersxs:integer
useExternalMessageReferencesxs:boolean
ElementTypeDescription
journal<spring:bean/>
longTermPersistencejdbcPersistenceAdapter | journalPersistenceAdapter | kahaPersistenceAdapter | memoryPersistenceAdapter | quickJournalPersistenceAdapter | rapidPersistenceAdapter
taskRunnerFactory<spring:bean/>
usageManagerusageManager

Element: journaledJDBC

AttributeTypeDescription
createTablesOnStartupxs:booleanSets whether or not tables are created on startup
dataDirectoryxs:string
dataDirectoryFilexs:string
journalArchiveDirectoryxs:string
journalLogFileSizexs:integerSets the size of the journal log files
journalLogFilesxs:integerSets the number of journal log files to use
journalThreadPriorityxs:integerSets the thread priority of the journal thread
useDatabaseLockxs:booleanSets whether or not an exclusive database lock should be used to enable JDBC Master/Slave. Enabled by default.
useJournalxs:booleanEnables or disables the use of the journal. The default is to use the journal
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 | imageBasedJDBCAdaptor | informixJDBCAdapter | oracleJDBCAdapter | streamJDBCAdapter
dataSource<spring:bean/>
jdbcAdapterjdbcPersistenceAdapter
journal<spring:bean/>
statementsstatements
taskRunnerFactory<spring:bean/>

Element: kahaPersistenceAdapter

AttributeTypeDescription
dirxs:string
indexTypexs:string
maxDataFileLengthxs:long
useExternalMessageReferencesxs:boolean
ElementTypeDescription
usageManagerusageManager

Element: lDAPAuthorizationMap

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

Element: lastImageSubscriptionRecoveryPolicy

Element: loggingBrokerPlugin

ElementTypeDescription
ackLog<spring:bean/>
adminConnectionContext<spring:bean/>
log<spring:bean/>
nextloggingBrokerPlugin | multicastTraceBrokerPlugin | udpTraceBrokerPlugin
pendingDurableSubscriberPolicyfileDurableSubscriberCursor | storeDurableSubscriberCursor | vmCursor
sendLog<spring:bean/>

Element: managementContext

AttributeTypeDescription
connectorPathxs:string
connectorPortxs:integer
createConnectorxs:boolean
createMBeanServerxs:boolean
findTigerMbeanServerxs:booleanEnables/disables the searching for the Java 5 platform MBeanServer
jmxDomainNamexs:string
rmiServerPortxs:integer
useMBeanServerxs:boolean
ElementTypeDescription
MBeanServer<spring:bean/>Get the MBeanServer
server<spring:bean/>

Element: masterConnector

AttributeTypeDescription
localURIxs:string
passwordxs:string
remoteURIxs:string
remoteUrixs:string
userNamexs:string
ElementTypeDescription
brokerServicebroker

Element: memoryPersistenceAdapter

AttributeTypeDescription
useExternalMessageReferencesxs:boolean
ElementTypeDescription
usageManagerusageManager

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).

Element: multicastNetworkConnector

AttributeTypeDescription
bridgeTempDestinationsxs:boolean
brokerNamexs:string
conduitSubscriptionsxs:boolean
decreaseNetworkConsumerPriorityxs:boolean
dispatchAsyncxs:boolean
dynamicOnlyxs:boolean
localUrixs:string
namexs:string
networkTTLxs:integer
passwordxs:string
prefetchSizexs:integer
remoteURIxs:stringSets the remote transport URI to some group transport like multicast://address:port
userNamexs:string
ElementTypeDescription
bridgecompositeDemandForwardingBridge | demandForwardingBridge
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/>
nextloggingBrokerPlugin | multicastTraceBrokerPlugin | udpTraceBrokerPlugin
pendingDurableSubscriberPolicyfileDurableSubscriberCursor | storeDurableSubscriberCursor | vmCursor
wireFormat<spring:bean/>
wireFormatFactory<spring:bean/>

Element: networkConnector

AttributeTypeDescription
bridgeTempDestinationsxs:boolean
brokerNamexs:string
conduitSubscriptionsxs:boolean
decreaseNetworkConsumerPriorityxs:boolean
discoveryURIxs:string
dispatchAsyncxs:boolean
dynamicOnlyxs:boolean
failoverxs:boolean
localUrixs:string
namexs:string
networkTTLxs:integer
passwordxs:string
prefetchSizexs:integer
urixs:string
userNamexs:string
ElementTypeDescription
connectionFilter<spring:bean/>
discoveryAgent<spring:bean/>
durableDestinations<spring:bean/>
dynamicallyIncludedDestinations(<spring:bean/>)*
excludedDestinations(<spring:bean/>)*
staticallyIncludedDestinations(<spring:bean/>)*

Element: noSubscriptionRecoveryPolicy

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: oracleJDBCAdapter

AttributeTypeDescription
batchStatmentsxs:boolean
useExternalMessageReferencesxs:boolean
ElementTypeDescription
statementsstatements

Element: outboundQueueBridge

AttributeTypeDescription
doHandleReplyToxs:boolean
localQueueNamexs:string
maximumRetriesxs:integerSets the maximum number of retries if a send fails before closing the bridge
outboundQueueNamexs:string
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
maximumRetriesxs:integerSets the maximum number of retries if a send fails before closing the bridge
outboundTopicNamexs:string
selectorxs:string
ElementTypeDescription
consumer<spring:bean/>
consumerConnection<spring:bean/>
consumerTopictopic
jmsConnectorjmsQueueConnector | jmsTopicConnector
jmsMessageConvertorsimpleJmsMessageConvertor
producerConnection<spring:bean/>
producerTopictopic

Element: policyEntry

AttributeTypeDescription
memoryLimitxs:long
queuexs:stringA helper method to set the destination from a configuration file
sendAdvisoryIfNoConsumersxs:booleanSends an advisory message if a non-persistent message is sent and there are no active consumers
topicxs:stringA helper method to set the destination from a configuration file
ElementTypeDescription
deadLetterStrategyindividualDeadLetterStrategy | sharedDeadLetterStrategySets the policy used to determine which dead letter queue destination should be used
destinationqueue | topic
dispatchPolicyroundRobinDispatchPolicy | simpleDispatchPolicy | strictOrderDispatchPolicy
messageEvictionStrategyoldestMessageEvictionStrategy | oldestMessageWithLowestPriorityEvictionStrategySets the eviction strategy used to decide which message to evict when the slow consumer needs to discard messages
messageGroupMapFactorymessageGroupHashBucketFactory | simpleMessageGroupMapFactorySets the factory used to create new instances of {MessageGroupMap} used to implement the Message Groups functionality.
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.
pendingQueueMessageStoragePolicy<spring:bean/>
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: 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: proxyConnector

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

Element: queryBasedSubscriptionRecoveryPolicy

ElementTypeDescription
query<spring:bean/>Sets the query strategy to load initial messages

Element: queue

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

Element: quickJournalPersistenceAdapter

AttributeTypeDescription
maxCheckpointMessageAddSizexs:integer
maxCheckpointWorkersxs:integer
useExternalMessageReferencesxs:boolean
ElementTypeDescription
journal<spring:bean/>
longTermPersistencejdbcPersistenceAdapter | journalPersistenceAdapter | kahaPersistenceAdapter | memoryPersistenceAdapter | quickJournalPersistenceAdapter | rapidPersistenceAdapter
taskRunnerFactory<spring:bean/>
usageManagerusageManager

Element: rapidPersistenceAdapter

AttributeTypeDescription
maxCheckpointMessageAddSizexs:integer
maxCheckpointWorkersxs:integer
useExternalMessageReferencesxs:boolean
ElementTypeDescription
journal<spring:bean/>
taskRunnerFactory<spring:bean/>
usageManagerusageManager

Element: redeliveryPolicy

AttributeTypeDescription
backOffMultiplierxs:short
collisionAvoidancePercentxs:short
initialRedeliveryDelayxs:long
maximumRedeliveriesxs:integer
useCollisionAvoidancexs:boolean
useExponentialBackOffxs:boolean

Element: roundRobinDispatchPolicy

Element: sharedDeadLetterStrategy

ElementTypeDescription
deadLetterQueuequeue | topic

Element: simpleAuthenticationPlugin

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

Element: simpleAuthorizationMap

ElementTypeDescription
adminACLsauthorizationMap | policyMap
readACLsauthorizationMap | policyMap
writeACLsauthorizationMap | policyMap

Element: simpleDispatchPolicy

Element: simpleJmsMessageConvertor

ElementTypeDescription
connection<spring:bean/>

Element: simpleMessageGroupMapFactory

Element: statements

AttributeTypeDescription
addMessageStatementxs:string
binaryDataTypexs:string
containerNameDataTypexs:string
createDurableSubStatementxs:string
deleteOldMessagesStatementxs:string
deleteSubscriptionStatementxs:string
durableSubAcksTableNamexs:string
durableSubscriberMessageCountStatementxs:string
findAllDestinationsStatementxs:string
findAllDurableSubMessagesStatementxs:string
findAllDurableSubsStatementxs:string
findAllMessagesStatementxs:string
findDurableSubMessagesStatementxs:string
findDurableSubStatementxs:string
findLastSequenceIdInAcksStatementxs:string
findLastSequenceIdInMsgsStatementxs:string
findMessageSequenceIdStatementxs:string
findMessageStatementxs:string
lockCreateStatementxs:string
lockTableNamexs:string
lockUpdateStatementxs:string
longDataTypexs:string
messageTableNamexs:string
msgIdDataTypexs:string
nextDurableSubscriberMessageIdStatementxs:string
nextDurableSubscriberMessageStatementxs:string
prevDurableSubscriberMessageIdStatementxs:string
removeAllMessagesStatementxs:string
removeAllSubscriptionsStatementxs:string
removeMessageStatmentxs:string
sequenceDataTypexs:string
stringIdDataTypexs:string
tablePrefixxs:string
updateLastAckOfDurableSubStatementxs:string
updateMessageStatementxs:string
useExternalMessageReferencesxs:boolean
useLockCreateWhereClausexs:boolean
ElementTypeDescription
createSchemaStatements(<spring:bean/>)*
dropSchemaStatements(<spring:bean/>)*

Element: storeDurableSubscriberCursor

Element: streamJDBCAdapter

AttributeTypeDescription
batchStatmentsxs:boolean
useExternalMessageReferencesxs:boolean
ElementTypeDescription
statementsstatements

Element: strictOrderDispatchPolicy

Element: timedSubscriptionRecoveryPolicy

AttributeTypeDescription
recoverDurationxs:long

Element: topic

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

Element: transportConnector

AttributeTypeDescription
brokerNamexs:string
connectUrixs:string
disableAsyncDispatchxs:boolean
discoveryUrixs:string
enableStatusMonitorxs:boolean
namexs: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
brokerloggingBrokerPlugin | multicastTraceBrokerPlugin | udpTraceBrokerPlugin
brokerInfo<spring:bean/>
discoveryAgent<spring:bean/>
messageAuthorizationPolicy<spring:bean/>Sets the policy used to decide if the current connection is authorized to consume a given message
server<spring:bean/>
taskRunnerFactory<spring:bean/>

Element: udpTraceBrokerPlugin

AttributeTypeDescription
broadcastxs:boolean
destinationxs:string
maxTraceDatagramSizexs:integer
ElementTypeDescription
address<spring:bean/>
adminConnectionContext<spring:bean/>
nextloggingBrokerPlugin | multicastTraceBrokerPlugin | udpTraceBrokerPlugin
pendingDurableSubscriberPolicyfileDurableSubscriberCursor | storeDurableSubscriberCursor | vmCursor
wireFormat<spring:bean/>
wireFormatFactory<spring:bean/>

Element: usageManager

AttributeTypeDescription
limitxs:longSets the memory limit in bytes. When set using XBean, you can use values such as: "20 mb", "1024 kb", or "1 gb"
percentUsagexs:integer
percentUsageMinDeltaxs:integerSets the minimum number of percentage points the usage has to change before a UsageListener event is fired by the manager.
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
ElementTypeDescription
parentusageManager

Element: virtualDestinationInterceptor

ElementTypeDescription
virtualDestinations(compositeQueue | compositeTopic | virtualTopic)*

Element: virtualTopic

AttributeTypeDescription
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

Element: vmCursor

Element: xaConnectionFactory

AttributeTypeDescription
alwaysSessionAsyncxs:booleanIf this flag is 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
beanNamexs:string
brokerURLxs:stringSets the connection URL used to connect to the ActiveMQ broker.
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
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.
nestedMapAndListEnabledxs:booleanEnables/disables whether or not Message properties and MapMessage entries support Nested Structures of Map and List objects
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
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
statsEnabledxs:boolean
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
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
ElementTypeDescription
clientIdGenerator<spring:bean/>
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 redelivery policy to be used when a message is delivered but the session is rolled back