You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@activemq.apache.org by ch...@apache.org on 2012/09/25 16:32:31 UTC

svn commit: r1389882 [4/7] - in /activemq/trunk: ./ activemq-core/ activemq-core/src/main/java/org/apache/activemq/store/leveldb/ activemq-core/src/main/resources/ activemq-core/src/main/resources/META-INF/ activemq-core/src/main/resources/META-INF/ser...

Added: activemq/trunk/activemq-core/src/main/resources/activemq.xsd.wiki
URL: http://svn.apache.org/viewvc/activemq/trunk/activemq-core/src/main/resources/activemq.xsd.wiki?rev=1389882&view=auto
==============================================================================
--- activemq/trunk/activemq-core/src/main/resources/activemq.xsd.wiki (added)
+++ activemq/trunk/activemq-core/src/main/resources/activemq.xsd.wiki Tue Sep 25 14:32:28 2012
@@ -0,0 +1,3789 @@
+h3. Elements By Type
+{anchor:org.apache.activemq.util.IOExceptionHandler-types}
+h4. The _[org.apache.activemq.util.IOExceptionHandler|#org.apache.activemq.util.IOExceptionHandler-types]_ Type Implementations
+    | _[<defaultIOExceptionHandler>|#defaultIOExceptionHandler-element]_ | {html}{html} |
+    | _[<jDBCIOExceptionHandler>|#jDBCIOExceptionHandler-element]_ | {html}{html} |
+
+{anchor:org.apache.activemq.security.AuthorizationMap-types}
+h4. The _[org.apache.activemq.security.AuthorizationMap|#org.apache.activemq.security.AuthorizationMap-types]_ Type Implementations
+    | _[<authorizationMap>|#authorizationMap-element]_ | {html}Represents 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.{html} |
+    | _[<cachedLDAPAuthorizationMap>|#cachedLDAPAuthorizationMap-element]_ | {html}A {@link DefaultAuthorizationMap} implementation which uses LDAP to initialize and update authorization
+policy.{html} |
+    | _[<lDAPAuthorizationMap>|#lDAPAuthorizationMap-element]_ | {html}An {@link AuthorizationMap} which uses LDAP{html} |
+    | _[<simpleAuthorizationMap>|#simpleAuthorizationMap-element]_ | {html}An AuthorizationMap which is configured with individual DestinationMaps for
+each operation.{html} |
+
+{anchor:org.apache.activemq.usage.SystemUsage-types}
+h4. The _[org.apache.activemq.usage.SystemUsage|#org.apache.activemq.usage.SystemUsage-types]_ Type Implementations
+    | _[<systemUsage>|#systemUsage-element]_ | {html}Holder for Usage instances for memory, store and temp files Main use case is
+manage memory usage.{html} |
+
+{anchor:org.apache.activemq.store.jdbc.JDBCAdapter-types}
+h4. The _[org.apache.activemq.store.jdbc.JDBCAdapter|#org.apache.activemq.store.jdbc.JDBCAdapter-types]_ Type Implementations
+    | _[<axionJDBCAdapter>|#axionJDBCAdapter-element]_ | {html}Axion 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.{html} |
+    | _[<blobJDBCAdapter>|#blobJDBCAdapter-element]_ | {html}This 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:
+<ul>
+<li></li>
+</ul>{html} |
+    | _[<bytesJDBCAdapter>|#bytesJDBCAdapter-element]_ | {html}This JDBCAdapter inserts and extracts BLOB data using the
+setBytes()/getBytes() operations. The databases/JDBC drivers that use this
+adapter are:{html} |
+    | _[<db2JDBCAdapter>|#db2JDBCAdapter-element]_ | {html}{html} |
+    | _[<defaultJDBCAdapter>|#defaultJDBCAdapter-element]_ | {html}Implements all the default JDBC operations that are used by the JDBCPersistenceAdapter. <p/> sub-classing is
+encouraged to override the default implementation of methods to account for differences in JDBC Driver
+implementations. <p/> The JDBCAdapter inserts and extracts BLOB data using the getBytes()/setBytes() operations. <p/>
+The databases/JDBC drivers that use this adapter are:
+<ul>
+<li></li>
+</ul>{html} |
+    | _[<hsqldb-jdbc-adapter>|#hsqldb-jdbc-adapter-element]_ | {html}{html} |
+    | _[<imageBasedJDBCAdaptor>|#imageBasedJDBCAdaptor-element]_ | {html}Provides JDBCAdapter since that uses
+IMAGE datatype to hold binary data.
+
+The databases/JDBC drivers that use this adapter are:
+<ul>
+<li>Sybase</li>
+<li>MS SQL</li>
+</ul>{html} |
+    | _[<informixJDBCAdapter>|#informixJDBCAdapter-element]_ | {html}JDBC Adapter for Informix database.
+Because Informix database restricts length of composite primary keys, length of 
+<i>container name</i> field and <i>subscription id</i> field must be reduced to 150 characters.
+Therefore be sure not to use longer names for container name and subscription id than 150 characters.{html} |
+    | _[<maxdb-jdbc-adapter>|#maxdb-jdbc-adapter-element]_ | {html}JDBC Adapter for the MaxDB database.{html} |
+    | _[<mysql-jdbc-adapter>|#mysql-jdbc-adapter-element]_ | {html}{html} |
+    | _[<oracleBlobJDBCAdapter>|#oracleBlobJDBCAdapter-element]_ | {html}Implements all the default JDBC operations that are used
+by the JDBCPersistenceAdapter.
+<p/>
+Subclassing is encouraged to override the default
+implementation of methods to account for differences
+in JDBC Driver implementations.
+<p/>
+The JDBCAdapter inserts and extracts BLOB data using the
+getBytes()/setBytes() operations.
+<p/>
+The databases/JDBC drivers that use this adapter are:
+<ul>
+<li></li>
+</ul>{html} |
+    | _[<oracleJDBCAdapter>|#oracleJDBCAdapter-element]_ | {html}Implements all the default JDBC operations that are used
+by the JDBCPersistenceAdapter.
+<p/>
+Subclassing is encouraged to override the default
+implementation of methods to account for differences
+in JDBC Driver implementations.
+<p/>{html} |
+    | _[<postgresql-jdbc-adapter>|#postgresql-jdbc-adapter-element]_ | {html}Implements all the default JDBC operations that are used
+by the JDBCPersistenceAdapter.
+<p/>
+Subclassing is encouraged to override the default
+implementation of methods to account for differences
+in JDBC Driver implementations.
+<p/>
+The JDBCAdapter inserts and extracts BLOB data using the
+getBytes()/setBytes() operations.
+<p/>
+The databases/JDBC drivers that use this adapter are:
+<ul>
+<li></li>
+</ul>{html} |
+    | _[<streamJDBCAdapter>|#streamJDBCAdapter-element]_ | {html}This JDBCAdapter inserts and extracts BLOB data using the
+setBinaryStream()/getBinaryStream() operations.
+
+The databases/JDBC drivers that use this adapter are:
+<ul>
+<li>Axion</li>
+</ul>{html} |
+    | _[<sybase-jdbc-adapter>|#sybase-jdbc-adapter-element]_ | {html}A JDBC Adapter for Sybase databases{html} |
+    | _[<transact-jdbc-adapter>|#transact-jdbc-adapter-element]_ | {html}A JDBC Adapter for Transact-SQL based databases such as SQL Server or Sybase{html} |
+
+{anchor:javax.jms.Queue-types}
+h4. The _[javax.jms.Queue|#javax.jms.Queue-types]_ Type Implementations
+    | _[<queue>|#queue-element]_ | {html}An ActiveMQ Queue{html} |
+
+{anchor:org.apache.activemq.broker.region.policy.SlowConsumerStrategy-types}
+h4. The _[org.apache.activemq.broker.region.policy.SlowConsumerStrategy|#org.apache.activemq.broker.region.policy.SlowConsumerStrategy-types]_ Type Implementations
+    | _[<abortSlowConsumerStrategy>|#abortSlowConsumerStrategy-element]_ | {html}Abort slow consumers when they reach the configured threshold of slowness, default is slow for 30 seconds{html} |
+
+{anchor:org.apache.activemq.network.NetworkConnector-types}
+h4. The _[org.apache.activemq.network.NetworkConnector|#org.apache.activemq.network.NetworkConnector-types]_ Type Implementations
+    | _[<ldapNetworkConnector>|#ldapNetworkConnector-element]_ | {html}class 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.{html} |
+    | _[<multicastNetworkConnector>|#multicastNetworkConnector-element]_ | {html}A 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.{html} |
+    | _[<networkConnector>|#networkConnector-element]_ | {html}A network connector which uses a discovery agent to detect the remote brokers
+available and setup a connection to each available remote broker{html} |
+
+{anchor:org.apache.activemq.broker.region.virtual.VirtualDestination-types}
+h4. The _[org.apache.activemq.broker.region.virtual.VirtualDestination|#org.apache.activemq.broker.region.virtual.VirtualDestination-types]_ Type Implementations
+    | _[<compositeQueue>|#compositeQueue-element]_ | {html}Represents a virtual queue which forwards to a number of other destinations.{html} |
+    | _[<compositeTopic>|#compositeTopic-element]_ | {html}Represents a virtual topic which forwards to a number of other destinations.{html} |
+    | _[<virtualTopic>|#virtualTopic-element]_ | {html}Creates <a href="http://activemq.org/site/virtual-destinations.html">Virtual
+Topics</a> using a prefix and postfix. The virtual destination creates a
+wildcard that is then used to look up all active queue subscriptions which
+match.{html} |
+
+{anchor:javax.jms.Destination-types}
+h4. The _[javax.jms.Destination|#javax.jms.Destination-types]_ Type Implementations
+    | _[<queue>|#queue-element]_ | {html}An ActiveMQ Queue{html} |
+    | _[<tempQueue>|#tempQueue-element]_ | {html}An ActiveMQ Temporary Queue Destination{html} |
+    | _[<tempTopic>|#tempTopic-element]_ | {html}An ActiveMQ Temporary Topic Destination{html} |
+    | _[<topic>|#topic-element]_ | {html}An ActiveMQ Topic{html} |
+
+{anchor:org.apache.activemq.store.jdbc.JDBCPersistenceAdapter-types}
+h4. The _[org.apache.activemq.store.jdbc.JDBCPersistenceAdapter|#org.apache.activemq.store.jdbc.JDBCPersistenceAdapter-types]_ Type Implementations
+    | _[<jdbcPersistenceAdapter>|#jdbcPersistenceAdapter-element]_ | {html}A {@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.{html} |
+
+{anchor:org.apache.activemq.store.PersistenceAdapterFactory-types}
+h4. The _[org.apache.activemq.store.PersistenceAdapterFactory|#org.apache.activemq.store.PersistenceAdapterFactory-types]_ Type Implementations
+    | _[<amqPersistenceAdapterFactory>|#amqPersistenceAdapterFactory-element]_ | {html}An implementation of {@link PersistenceAdapterFactory}{html} |
+    | _[<journalPersistenceAdapterFactory>|#journalPersistenceAdapterFactory-element]_ | {html}Factory class that can create PersistenceAdapter objects.{html} |
+    | _[<journaledJDBC>|#journaledJDBC-element]_ | {html}Creates a default persistence model using the Journal and JDBC{html} |
+
+{anchor:org.apache.activemq.usage.MemoryUsage-types}
+h4. The _[org.apache.activemq.usage.MemoryUsage|#org.apache.activemq.usage.MemoryUsage-types]_ Type Implementations
+    | _[<memoryUsage>|#memoryUsage-element]_ | {html}Used 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.{html} |
+
+{anchor:org.apache.activemq.broker.region.policy.DispatchPolicy-types}
+h4. The _[org.apache.activemq.broker.region.policy.DispatchPolicy|#org.apache.activemq.broker.region.policy.DispatchPolicy-types]_ Type Implementations
+    | _[<priorityNetworkDispatchPolicy>|#priorityNetworkDispatchPolicy-element]_ | {html}dispatch policy that ignores lower priority duplicate network consumers,
+used in conjunction with network bridge suppresDuplicateTopicSubscriptions{html} |
+    | _[<roundRobinDispatchPolicy>|#roundRobinDispatchPolicy-element]_ | {html}Simple dispatch policy that sends a message to every subscription that
+matches the message.{html} |
+    | _[<simpleDispatchPolicy>|#simpleDispatchPolicy-element]_ | {html}Simple dispatch policy that sends a message to every subscription that
+matches the message.{html} |
+    | _[<strictOrderDispatchPolicy>|#strictOrderDispatchPolicy-element]_ | {html}Dispatch policy that causes every subscription to see messages in the same
+order.{html} |
+
+{anchor:org.apache.activemq.usage.TempUsage-types}
+h4. The _[org.apache.activemq.usage.TempUsage|#org.apache.activemq.usage.TempUsage-types]_ Type Implementations
+    | _[<tempUsage>|#tempUsage-element]_ | {html}Used 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.{html} |
+
+{anchor:org.apache.activemq.usage.StoreUsage-types}
+h4. The _[org.apache.activemq.usage.StoreUsage|#org.apache.activemq.usage.StoreUsage-types]_ Type Implementations
+    | _[<storeUsage>|#storeUsage-element]_ | {html}Used 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.{html} |
+
+{anchor:org.apache.activemq.network.jms.ReconnectionPolicy-types}
+h4. The _[org.apache.activemq.network.jms.ReconnectionPolicy|#org.apache.activemq.network.jms.ReconnectionPolicy-types]_ Type Implementations
+    | _[<reconnectionPolicy>|#reconnectionPolicy-element]_ | {html}A policy object that defines how a {@link JmsConnector} deals with
+reconnection of the local and foreign connections.{html} |
+
+{anchor:org.apache.activemq.broker.region.policy.SubscriptionRecoveryPolicy-types}
+h4. The _[org.apache.activemq.broker.region.policy.SubscriptionRecoveryPolicy|#org.apache.activemq.broker.region.policy.SubscriptionRecoveryPolicy-types]_ Type Implementations
+    | _[<fixedCountSubscriptionRecoveryPolicy>|#fixedCountSubscriptionRecoveryPolicy-element]_ | {html}This implementation of {@link SubscriptionRecoveryPolicy} will keep a fixed
+count of last messages.{html} |
+    | _[<fixedSizedSubscriptionRecoveryPolicy>|#fixedSizedSubscriptionRecoveryPolicy-element]_ | {html}This implementation of {@link SubscriptionRecoveryPolicy} will keep a fixed
+amount of memory available in RAM for message history which is evicted in
+time order.{html} |
+    | _[<lastImageSubscriptionRecoveryPolicy>|#lastImageSubscriptionRecoveryPolicy-element]_ | {html}This implementation of {@link SubscriptionRecoveryPolicy} will only keep the
+last message.{html} |
+    | _[<noSubscriptionRecoveryPolicy>|#noSubscriptionRecoveryPolicy-element]_ | {html}This SubscriptionRecoveryPolicy disable recovery of messages.{html} |
+    | _[<queryBasedSubscriptionRecoveryPolicy>|#queryBasedSubscriptionRecoveryPolicy-element]_ | {html}This implementation of {@link SubscriptionRecoveryPolicy} will perform a user
+specific query mechanism to load any messages they may have missed.{html} |
+    | _[<timedSubscriptionRecoveryPolicy>|#timedSubscriptionRecoveryPolicy-element]_ | {html}This implementation of {@link SubscriptionRecoveryPolicy} will keep a timed
+buffer of messages around in memory and use that to recover new
+subscriptions.{html} |
+
+{anchor:org.apache.activemq.thread.TaskRunnerFactory-types}
+h4. The _[org.apache.activemq.thread.TaskRunnerFactory|#org.apache.activemq.thread.TaskRunnerFactory-types]_ Type Implementations
+    | _[<taskRunnerFactory>|#taskRunnerFactory-element]_ | {html}Manages 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.{html} |
+
+{anchor:org.apache.activemq.broker.region.group.MessageGroupMapFactory-types}
+h4. The _[org.apache.activemq.broker.region.group.MessageGroupMapFactory|#org.apache.activemq.broker.region.group.MessageGroupMapFactory-types]_ Type Implementations
+    | _[<messageGroupHashBucketFactory>|#messageGroupHashBucketFactory-element]_ | {html}A factory to create instances of {@link SimpleMessageGroupMap} when
+implementing the <a
+href="http://activemq.apache.org/message-groups.html">Message
+Groups</a> functionality.{html} |
+    | _[<simpleMessageGroupMapFactory>|#simpleMessageGroupMapFactory-element]_ | {html}A factory to create instances of {@link SimpleMessageGroupMap} when implementing the 
+<a href="http://activemq.apache.org/message-groups.html">Message Groups</a> functionality.{html} |
+
+{anchor:org.apache.activemq.store.kahadb.plist.PListStore-types}
+h4. The _[org.apache.activemq.store.kahadb.plist.PListStore|#org.apache.activemq.store.kahadb.plist.PListStore-types]_ Type Implementations
+    | _[<pListStore>|#pListStore-element]_ | {html}{html} |
+
+{anchor:org.apache.activemq.broker.SslContext-types}
+h4. The _[org.apache.activemq.broker.SslContext|#org.apache.activemq.broker.SslContext-types]_ Type Implementations
+    | _[<sslContext>|#sslContext-element]_ | {html}Extends the SslContext so that it's easier to configure from spring.{html} |
+
+{anchor:javax.jms.ExceptionListener-types}
+h4. The _[javax.jms.ExceptionListener|#javax.jms.ExceptionListener-types]_ Type Implementations
+    | _[<commandAgent>|#commandAgent-element]_ | {html}An agent which listens to commands on a JMS destination{html} |
+
+{anchor:org.apache.activemq.store.kahadb.KahaDBPersistenceAdapter-types}
+h4. The _[org.apache.activemq.store.kahadb.KahaDBPersistenceAdapter|#org.apache.activemq.store.kahadb.KahaDBPersistenceAdapter-types]_ Type Implementations
+    | _[<kahaDB>|#kahaDB-element]_ | {html}An implementation of {@link PersistenceAdapter} designed for use with
+KahaDB - Embedded Lightweight Non-Relational Database{html} |
+
+{anchor:org.apache.activemq.broker.region.DestinationInterceptor-types}
+h4. The _[org.apache.activemq.broker.region.DestinationInterceptor|#org.apache.activemq.broker.region.DestinationInterceptor-types]_ Type Implementations
+    | _[<mirroredQueue>|#mirroredQueue-element]_ | {html}Creates <a href="http://activemq.org/site/mirrored-queues.html">Mirrored
+Queue</a> using a prefix and postfix to define the topic name on which to mirror the queue to.{html} |
+    | _[<virtualDestinationInterceptor>|#virtualDestinationInterceptor-element]_ | {html}Implements <a
+href="http://activemq.apache.org/virtual-destinations.html">Virtual Topics</a>.{html} |
+
+{anchor:org.apache.activemq.network.jms.InboundQueueBridge-types}
+h4. The _[org.apache.activemq.network.jms.InboundQueueBridge|#org.apache.activemq.network.jms.InboundQueueBridge-types]_ Type Implementations
+    | _[<inboundQueueBridge>|#inboundQueueBridge-element]_ | {html}Create 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.{html} |
+
+{anchor:org.apache.activemq.broker.BrokerService-types}
+h4. The _[org.apache.activemq.broker.BrokerService|#org.apache.activemq.broker.BrokerService-types]_ Type Implementations
+    | _[<broker>|#broker-element]_ | {html}An 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.{html} |
+    | _[<brokerService>|#brokerService-element]_ | {html}Manages the lifecycle 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.{html} |
+
+{anchor:org.apache.activemq.network.DemandForwardingBridgeSupport-types}
+h4. The _[org.apache.activemq.network.DemandForwardingBridgeSupport|#org.apache.activemq.network.DemandForwardingBridgeSupport-types]_ Type Implementations
+    | _[<compositeDemandForwardingBridge>|#compositeDemandForwardingBridge-element]_ | {html}A demand forwarding bridge which works with multicast style transports where
+a single Transport could be communicating with multiple remote brokers{html} |
+    | _[<demandForwardingBridge>|#demandForwardingBridge-element]_ | {html}Forwards messages from the local broker to the remote broker based on demand.{html} |
+
+{anchor:javax.jms.QueueConnectionFactory-types}
+h4. The _[javax.jms.QueueConnectionFactory|#javax.jms.QueueConnectionFactory-types]_ Type Implementations
+    | _[<connectionFactory>|#connectionFactory-element]_ | {html}A <a href="http://www.springframework.org/">Spring</a> 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 <a href="http://activemq.apache.org/jmx.html">JMX</a>.{html} |
+    | _[<xaConnectionFactory>|#xaConnectionFactory-element]_ | {html}A <a href="http://www.springframework.org/">Spring</a> 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 <a href="http://activemq.apache.org/jmx.html">JMX</a>.{html} |
+
+{anchor:org.apache.activemq.ActiveMQPrefetchPolicy-types}
+h4. The _[org.apache.activemq.ActiveMQPrefetchPolicy|#org.apache.activemq.ActiveMQPrefetchPolicy-types]_ Type Implementations
+    | _[<prefetchPolicy>|#prefetchPolicy-element]_ | {html}Defines the prefetch message policies for different types of consumers{html} |
+
+{anchor:org.apache.activemq.broker.region.policy.PolicyMap-types}
+h4. The _[org.apache.activemq.broker.region.policy.PolicyMap|#org.apache.activemq.broker.region.policy.PolicyMap-types]_ Type Implementations
+    | _[<policyMap>|#policyMap-element]_ | {html}Represents a destination based configuration of policies so that individual
+destinations or wildcard hierarchies of destinations can be configured using
+different policies.{html} |
+
+{anchor:org.apache.activemq.network.jms.OutboundTopicBridge-types}
+h4. The _[org.apache.activemq.network.jms.OutboundTopicBridge|#org.apache.activemq.network.jms.OutboundTopicBridge-types]_ Type Implementations
+    | _[<outboundTopicBridge>|#outboundTopicBridge-element]_ | {html}Create 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.{html} |
+
+{anchor:org.apache.activemq.RedeliveryPolicy-types}
+h4. The _[org.apache.activemq.RedeliveryPolicy|#org.apache.activemq.RedeliveryPolicy-types]_ Type Implementations
+    | _[<redeliveryPolicy>|#redeliveryPolicy-element]_ | {html}Configuration 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 RedeliveryPlugin{html} |
+
+{anchor:org.apache.activemq.Service-types}
+h4. The _[org.apache.activemq.Service|#org.apache.activemq.Service-types]_ Type Implementations
+    | _[<broker>|#broker-element]_ | {html}An 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.{html} |
+    | _[<brokerService>|#brokerService-element]_ | {html}Manages the lifecycle 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.{html} |
+    | _[<commandAgent>|#commandAgent-element]_ | {html}An agent which listens to commands on a JMS destination{html} |
+    | _[<database-locker>|#database-locker-element]_ | {html}Represents an exclusive lock on a database to avoid multiple brokers running
+against the same logical database.{html} |
+    | _[<forwardingBridge>|#forwardingBridge-element]_ | {html}Forwards all messages from the local broker to the remote broker.{html} |
+    | _[<inboundQueueBridge>|#inboundQueueBridge-element]_ | {html}Create 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.{html} |
+    | _[<inboundTopicBridge>|#inboundTopicBridge-element]_ | {html}Create 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.{html} |
+    | _[<jdbcPersistenceAdapter>|#jdbcPersistenceAdapter-element]_ | {html}A {@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.{html} |
+    | _[<jmsQueueConnector>|#jmsQueueConnector-element]_ | {html}A Bridge to other JMS Queue providers{html} |
+    | _[<jmsTopicConnector>|#jmsTopicConnector-element]_ | {html}A Bridge to other JMS Topic providers{html} |
+    | _[<journalPersistenceAdapterFactory>|#journalPersistenceAdapterFactory-element]_ | {html}Factory class that can create PersistenceAdapter objects.{html} |
+    | _[<journaledJDBC>|#journaledJDBC-element]_ | {html}Creates a default persistence model using the Journal and JDBC{html} |
+    | _[<kahaDB>|#kahaDB-element]_ | {html}An implementation of {@link PersistenceAdapter} designed for use with
+KahaDB - Embedded Lightweight Non-Relational Database{html} |
+    | _[<ldapNetworkConnector>|#ldapNetworkConnector-element]_ | {html}class 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.{html} |
+    | _[<lease-database-locker>|#lease-database-locker-element]_ | {html}Represents an exclusive lease on a database to avoid multiple brokers running
+against the same logical database.{html} |
+    | _[<levelDB>|#levelDB-element]_ | {html}An implementation of {@link org.apache.activemq.store.PersistenceAdapter} designed for use with
+LevelDB - Embedded Lightweight Non-Relational Database{html} |
+    | _[<managementContext>|#managementContext-element]_ | {html}An abstraction over JMX mbean registration{html} |
+    | _[<masterConnector>|#masterConnector-element]_ | {html}Connects a Slave Broker to a Master when using <a
+href="http://activemq.apache.org/masterslave.html">Master Slave</a> for High
+Availability of messages.{html} |
+    | _[<memoryUsage>|#memoryUsage-element]_ | {html}Used 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.{html} |
+    | _[<multicastNetworkConnector>|#multicastNetworkConnector-element]_ | {html}A 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.{html} |
+    | _[<networkConnector>|#networkConnector-element]_ | {html}A network connector which uses a discovery agent to detect the remote brokers
+available and setup a connection to each available remote broker{html} |
+    | _[<outboundQueueBridge>|#outboundQueueBridge-element]_ | {html}Create 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.{html} |
+    | _[<outboundTopicBridge>|#outboundTopicBridge-element]_ | {html}Create 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.{html} |
+    | _[<pListStore>|#pListStore-element]_ | {html}{html} |
+    | _[<proxyConnector>|#proxyConnector-element]_ | {html}{html} |
+    | _[<shared-file-locker>|#shared-file-locker-element]_ | {html}Represents an exclusive lock on a database to avoid multiple brokers running
+against the same logical database.{html} |
+    | _[<storeUsage>|#storeUsage-element]_ | {html}Used 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.{html} |
+    | _[<systemUsage>|#systemUsage-element]_ | {html}Holder for Usage instances for memory, store and temp files Main use case is
+manage memory usage.{html} |
+    | _[<tempUsage>|#tempUsage-element]_ | {html}Used 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.{html} |
+    | _[<transact-database-locker>|#transact-database-locker-element]_ | {html}Represents an exclusive lock on a database to avoid multiple brokers running
+against the same logical database.{html} |
+
+{anchor:org.apache.activemq.broker.region.policy.DeadLetterStrategy-types}
+h4. The _[org.apache.activemq.broker.region.policy.DeadLetterStrategy|#org.apache.activemq.broker.region.policy.DeadLetterStrategy-types]_ Type Implementations
+    | _[<individualDeadLetterStrategy>|#individualDeadLetterStrategy-element]_ | {html}A {@link DeadLetterStrategy} where each destination has its own individual
+DLQ using the subject naming hierarchy.{html} |
+    | _[<sharedDeadLetterStrategy>|#sharedDeadLetterStrategy-element]_ | {html}A default implementation of {@link DeadLetterStrategy} which uses
+a constant destination.{html} |
+
+{anchor:org.apache.activemq.command.ActiveMQDestination-types}
+h4. The _[org.apache.activemq.command.ActiveMQDestination|#org.apache.activemq.command.ActiveMQDestination-types]_ Type Implementations
+    | _[<queue>|#queue-element]_ | {html}An ActiveMQ Queue{html} |
+    | _[<tempQueue>|#tempQueue-element]_ | {html}An ActiveMQ Temporary Queue Destination{html} |
+    | _[<tempTopic>|#tempTopic-element]_ | {html}An ActiveMQ Temporary Topic Destination{html} |
+    | _[<topic>|#topic-element]_ | {html}An ActiveMQ Topic{html} |
+
+{anchor:org.apache.activemq.security.TempDestinationAuthorizationEntry-types}
+h4. The _[org.apache.activemq.security.TempDestinationAuthorizationEntry|#org.apache.activemq.security.TempDestinationAuthorizationEntry-types]_ Type Implementations
+    | _[<tempDestinationAuthorizationEntry>|#tempDestinationAuthorizationEntry-element]_ | {html}Represents an entry in a {@link DefaultAuthorizationMap} for assigning
+different operations (read, write, admin) of user roles to a temporary
+destination{html} |
+
+{anchor:javax.jms.Topic-types}
+h4. The _[javax.jms.Topic|#javax.jms.Topic-types]_ Type Implementations
+    | _[<topic>|#topic-element]_ | {html}An ActiveMQ Topic{html} |
+
+{anchor:org.apache.activemq.broker.region.policy.PendingDurableSubscriberMessageStoragePolicy-types}
+h4. The _[org.apache.activemq.broker.region.policy.PendingDurableSubscriberMessageStoragePolicy|#org.apache.activemq.broker.region.policy.PendingDurableSubscriberMessageStoragePolicy-types]_ Type Implementations
+    | _[<fileDurableSubscriberCursor>|#fileDurableSubscriberCursor-element]_ | {html}Pending messages for durable subscribers{html} |
+    | _[<storeDurableSubscriberCursor>|#storeDurableSubscriberCursor-element]_ | {html}Pending messages for a durable{html} |
+    | _[<vmDurableCursor>|#vmDurableCursor-element]_ | {html}Pending{html} |
+
+{anchor:javax.jms.TopicConnectionFactory-types}
+h4. The _[javax.jms.TopicConnectionFactory|#javax.jms.TopicConnectionFactory-types]_ Type Implementations
+    | _[<connectionFactory>|#connectionFactory-element]_ | {html}A <a href="http://www.springframework.org/">Spring</a> 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 <a href="http://activemq.apache.org/jmx.html">JMX</a>.{html} |
+    | _[<xaConnectionFactory>|#xaConnectionFactory-element]_ | {html}A <a href="http://www.springframework.org/">Spring</a> 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 <a href="http://activemq.apache.org/jmx.html">JMX</a>.{html} |
+
+{anchor:org.apache.activemq.store.jdbc.Statements-types}
+h4. The _[org.apache.activemq.store.jdbc.Statements|#org.apache.activemq.store.jdbc.Statements-types]_ Type Implementations
+    | _[<statements>|#statements-element]_ | {html}{html} |
+
+{anchor:org.apache.activemq.security.AuthorizationEntry-types}
+h4. The _[org.apache.activemq.security.AuthorizationEntry|#org.apache.activemq.security.AuthorizationEntry-types]_ Type Implementations
+    | _[<authorizationEntry>|#authorizationEntry-element]_ | {html}Represents 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.{html} |
+    | _[<tempDestinationAuthorizationEntry>|#tempDestinationAuthorizationEntry-element]_ | {html}Represents an entry in a {@link DefaultAuthorizationMap} for assigning
+different operations (read, write, admin) of user roles to a temporary
+destination{html} |
+
+{anchor:org.apache.activemq.filter.DestinationMap-types}
+h4. The _[org.apache.activemq.filter.DestinationMap|#org.apache.activemq.filter.DestinationMap-types]_ Type Implementations
+    | _[<authorizationMap>|#authorizationMap-element]_ | {html}Represents 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.{html} |
+    | _[<cachedLDAPAuthorizationMap>|#cachedLDAPAuthorizationMap-element]_ | {html}A {@link DefaultAuthorizationMap} implementation which uses LDAP to initialize and update authorization
+policy.{html} |
+    | _[<mKahaDB>|#mKahaDB-element]_ | {html}An implementation of {@link org.apache.activemq.store.PersistenceAdapter}  that supports
+distribution of destinations across multiple kahaDB persistence adapters{html} |
+    | _[<policyMap>|#policyMap-element]_ | {html}Represents a destination based configuration of policies so that individual
+destinations or wildcard hierarchies of destinations can be configured using
+different policies.{html} |
+    | _[<redeliveryPolicyMap>|#redeliveryPolicyMap-element]_ | {html}Represents a destination based configuration of policies so that individual
+destinations or wildcard hierarchies of destinations can be configured using
+different policies.{html} |
+
+{anchor:org.apache.activemq.network.NetworkBridgeConfiguration-types}
+h4. The _[org.apache.activemq.network.NetworkBridgeConfiguration|#org.apache.activemq.network.NetworkBridgeConfiguration-types]_ Type Implementations
+    | _[<ldapNetworkConnector>|#ldapNetworkConnector-element]_ | {html}class 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.{html} |
+    | _[<multicastNetworkConnector>|#multicastNetworkConnector-element]_ | {html}A 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.{html} |
+    | _[<networkConnector>|#networkConnector-element]_ | {html}A network connector which uses a discovery agent to detect the remote brokers
+available and setup a connection to each available remote broker{html} |
+
+{anchor:org.apache.activemq.broker.region.policy.PendingQueueMessageStoragePolicy-types}
+h4. The _[org.apache.activemq.broker.region.policy.PendingQueueMessageStoragePolicy|#org.apache.activemq.broker.region.policy.PendingQueueMessageStoragePolicy-types]_ Type Implementations
+    | _[<fileQueueCursor>|#fileQueueCursor-element]_ | {html}Pending{html} |
+    | _[<storeCursor>|#storeCursor-element]_ | {html}Pending messages{html} |
+    | _[<vmQueueCursor>|#vmQueueCursor-element]_ | {html}Pending messages{html} |
+
+{anchor:org.apache.activemq.broker.region.policy.RedeliveryPolicyMap-types}
+h4. The _[org.apache.activemq.broker.region.policy.RedeliveryPolicyMap|#org.apache.activemq.broker.region.policy.RedeliveryPolicyMap-types]_ Type Implementations
+    | _[<redeliveryPolicyMap>|#redeliveryPolicyMap-element]_ | {html}Represents a destination based configuration of policies so that individual
+destinations or wildcard hierarchies of destinations can be configured using
+different policies.{html} |
+
+{anchor:org.apache.activemq.broker.region.policy.PendingSubscriberMessageStoragePolicy-types}
+h4. The _[org.apache.activemq.broker.region.policy.PendingSubscriberMessageStoragePolicy|#org.apache.activemq.broker.region.policy.PendingSubscriberMessageStoragePolicy-types]_ Type Implementations
+    | _[<fileCursor>|#fileCursor-element]_ | {html}Pending messages{html} |
+    | _[<vmCursor>|#vmCursor-element]_ | {html}Pending messages held{html} |
+
+{anchor:org.apache.activemq.network.NetworkBridgeFilterFactory-types}
+h4. The _[org.apache.activemq.network.NetworkBridgeFilterFactory|#org.apache.activemq.network.NetworkBridgeFilterFactory-types]_ Type Implementations
+    | _[<conditionalNetworkBridgeFilterFactory>|#conditionalNetworkBridgeFilterFactory-element]_ | {html}implement conditional behaviour for queue consumers,
+allows replaying back to origin if no consumers are present on the local broker
+after a configurable delay, irrespective of the networkTTL
+Also allows rate limiting of messages through the network, useful for static includes{html} |
+    | _[<defaultNetworkBridgeFilterFactory>|#defaultNetworkBridgeFilterFactory-element]_ | {html}implement default behaviour, filter that will not allow resend to origin
+based on brokerPath and which respects networkTTL{html} |
+
+{anchor:javax.jms.ConnectionFactory-types}
+h4. The _[javax.jms.ConnectionFactory|#javax.jms.ConnectionFactory-types]_ Type Implementations
+    | _[<connectionFactory>|#connectionFactory-element]_ | {html}A <a href="http://www.springframework.org/">Spring</a> 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 <a href="http://activemq.apache.org/jmx.html">JMX</a>.{html} |
+    | _[<xaConnectionFactory>|#xaConnectionFactory-element]_ | {html}A <a href="http://www.springframework.org/">Spring</a> 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 <a href="http://activemq.apache.org/jmx.html">JMX</a>.{html} |
+
+{anchor:org.apache.activemq.broker.region.policy.PolicyEntry-types}
+h4. The _[org.apache.activemq.broker.region.policy.PolicyEntry|#org.apache.activemq.broker.region.policy.PolicyEntry-types]_ Type Implementations
+    | _[<policyEntry>|#policyEntry-element]_ | {html}Represents an entry in a {@link PolicyMap} for assigning policies to a
+specific destination or a hierarchical wildcard area of destinations.{html} |
+
+{anchor:org.apache.activemq.broker.region.policy.PendingMessageLimitStrategy-types}
+h4. The _[org.apache.activemq.broker.region.policy.PendingMessageLimitStrategy|#org.apache.activemq.broker.region.policy.PendingMessageLimitStrategy-types]_ Type Implementations
+    | _[<constantPendingMessageLimitStrategy>|#constantPendingMessageLimitStrategy-element]_ | {html}This PendingMessageLimitStrategy is configured to a constant value for all subscriptions.{html} |
+    | _[<prefetchRatePendingMessageLimitStrategy>|#prefetchRatePendingMessageLimitStrategy-element]_ | {html}This PendingMessageLimitStrategy sets the maximum pending message limit value to be
+a multiplier of the prefetch limit of the subscription.{html} |
+
+{anchor:org.apache.activemq.usage.UsageCapacity-types}
+h4. The _[org.apache.activemq.usage.UsageCapacity|#org.apache.activemq.usage.UsageCapacity-types]_ Type Implementations
+    | _[<defaultUsageCapacity>|#defaultUsageCapacity-element]_ | {html}Identify if a limit has been reached{html} |
+    | _[<usageCapacity>|#usageCapacity-element]_ | {html}Identify if a limit has been reached{html} |
+
+{anchor:org.apache.activemq.broker.BrokerPlugin-types}
+h4. The _[org.apache.activemq.broker.BrokerPlugin|#org.apache.activemq.broker.BrokerPlugin-types]_ Type Implementations
+    | _[<authorizationPlugin>|#authorizationPlugin-element]_ | {html}An authorization plugin where each operation on a destination is checked
+against an authorizationMap{html} |
+    | _[<connectionDotFilePlugin>|#connectionDotFilePlugin-element]_ | {html}A <a href="http://www.graphviz.org/">DOT</a> file creator plugin which
+creates a DOT file showing the current connections{html} |
+    | _[<destinationDotFilePlugin>|#destinationDotFilePlugin-element]_ | {html}A <a href="http://www.graphviz.org/">DOT</a> 
+file creator plugin which creates a DOT file showing the current topic & queue hierarchies.{html} |
+    | _[<destinationPathSeparatorPlugin>|#destinationPathSeparatorPlugin-element]_ | {html}{html} |
+    | _[<discardingDLQBrokerPlugin>|#discardingDLQBrokerPlugin-element]_ | {html}{html} |
+    | _[<forcePersistencyModeBrokerPlugin>|#forcePersistencyModeBrokerPlugin-element]_ | {html}A 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.{html} |
+    | _[<jaasAuthenticationPlugin>|#jaasAuthenticationPlugin-element]_ | {html}Provides a JAAS based authentication plugin{html} |
+    | _[<jaasCertificateAuthenticationPlugin>|#jaasCertificateAuthenticationPlugin-element]_ | {html}Provides a JAAS based SSL certificate authentication plugin{html} |
+    | _[<jaasDualAuthenticationPlugin>|#jaasDualAuthenticationPlugin-element]_ | {html}Provides a JAAS based authentication plugin{html} |
+    | _[<loggingBrokerPlugin>|#loggingBrokerPlugin-element]_ | {html}A simple Broker intercepter which allows you to enable/disable logging.{html} |
+    | _[<multicastTraceBrokerPlugin>|#multicastTraceBrokerPlugin-element]_ | {html}A Broker interceptor which allows you to trace all operations to a Multicast
+socket.{html} |
+    | _[<redeliveryPlugin>|#redeliveryPlugin-element]_ | {html}Replace 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 fallbackToDeadLetter{html} |
+    | _[<simpleAuthenticationPlugin>|#simpleAuthenticationPlugin-element]_ | {html}Provides a simple authentication plugin{html} |
+    | _[<statisticsBrokerPlugin>|#statisticsBrokerPlugin-element]_ | {html}A 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 target{html} |
+    | _[<timeStampingBrokerPlugin>|#timeStampingBrokerPlugin-element]_ | {html}A 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 time{html} |
+    | _[<traceBrokerPathPlugin>|#traceBrokerPathPlugin-element]_ | {html}The 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.{html} |
+    | _[<udpTraceBrokerPlugin>|#udpTraceBrokerPlugin-element]_ | {html}A Broker interceptor which allows you to trace all operations to a UDP
+socket.{html} |
+    | _[<virtualSelectorCacheBrokerPlugin>|#virtualSelectorCacheBrokerPlugin-element]_ | {html}A plugin which allows the caching of the selector from a subscription queue.
+<p/>
+This stops the build-up of unwanted messages, especially when consumers may
+disconnect from time to time when using virtual destinations.
+<p/>
+This is influenced by code snippets developed by Maciej Rakowicz{html} |
+
+{anchor:org.apache.activemq.network.jms.JmsMesageConvertor-types}
+h4. The _[org.apache.activemq.network.jms.JmsMesageConvertor|#org.apache.activemq.network.jms.JmsMesageConvertor-types]_ Type Implementations
+    | _[<simpleJmsMessageConvertor>|#simpleJmsMessageConvertor-element]_ | {html}Converts Message from one JMS to another{html} |
+
+{anchor:org.apache.activemq.broker.Broker-types}
+h4. The _[org.apache.activemq.broker.Broker|#org.apache.activemq.broker.Broker-types]_ Type Implementations
+    | _[<destinationPathSeparatorPlugin>|#destinationPathSeparatorPlugin-element]_ | {html}{html} |
+    | _[<forcePersistencyModeBroker>|#forcePersistencyModeBroker-element]_ | {html}A 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.{html} |
+    | _[<loggingBrokerPlugin>|#loggingBrokerPlugin-element]_ | {html}A simple Broker intercepter which allows you to enable/disable logging.{html} |
+    | _[<multicastTraceBrokerPlugin>|#multicastTraceBrokerPlugin-element]_ | {html}A Broker interceptor which allows you to trace all operations to a Multicast
+socket.{html} |
+    | _[<redeliveryPlugin>|#redeliveryPlugin-element]_ | {html}Replace 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 fallbackToDeadLetter{html} |
+    | _[<timeStampingBrokerPlugin>|#timeStampingBrokerPlugin-element]_ | {html}A 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 time{html} |
+    | _[<traceBrokerPathPlugin>|#traceBrokerPathPlugin-element]_ | {html}The 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.{html} |
+    | _[<udpTraceBrokerPlugin>|#udpTraceBrokerPlugin-element]_ | {html}A Broker interceptor which allows you to trace all operations to a UDP
+socket.{html} |
+
+{anchor:org.apache.activemq.broker.TransportConnector-types}
+h4. The _[org.apache.activemq.broker.TransportConnector|#org.apache.activemq.broker.TransportConnector-types]_ Type Implementations
+    | _[<transportConnector>|#transportConnector-element]_ | {html}{html} |
+
+{anchor:org.apache.activemq.network.jms.InboundTopicBridge-types}
+h4. The _[org.apache.activemq.network.jms.InboundTopicBridge|#org.apache.activemq.network.jms.InboundTopicBridge-types]_ Type Implementations
+    | _[<inboundTopicBridge>|#inboundTopicBridge-element]_ | {html}Create 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.{html} |
+
+{anchor:org.apache.activemq.network.jms.JmsConnector-types}
+h4. The _[org.apache.activemq.network.jms.JmsConnector|#org.apache.activemq.network.jms.JmsConnector-types]_ Type Implementations
+    | _[<jmsQueueConnector>|#jmsQueueConnector-element]_ | {html}A Bridge to other JMS Queue providers{html} |
+    | _[<jmsTopicConnector>|#jmsTopicConnector-element]_ | {html}A Bridge to other JMS Topic providers{html} |
+
+{anchor:org.apache.activemq.store.PersistenceAdapter-types}
+h4. The _[org.apache.activemq.store.PersistenceAdapter|#org.apache.activemq.store.PersistenceAdapter-types]_ Type Implementations
+    | _[<amqPersistenceAdapter>|#amqPersistenceAdapter-element]_ | {html}An 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.{html} |
+    | _[<jdbcPersistenceAdapter>|#jdbcPersistenceAdapter-element]_ | {html}A {@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.{html} |
+    | _[<journalPersistenceAdapter>|#journalPersistenceAdapter-element]_ | {html}An 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.{html} |
+    | _[<kahaDB>|#kahaDB-element]_ | {html}An implementation of {@link PersistenceAdapter} designed for use with
+KahaDB - Embedded Lightweight Non-Relational Database{html} |
+    | _[<kahaPersistenceAdapter>|#kahaPersistenceAdapter-element]_ | {html}{html} |
+    | _[<levelDB>|#levelDB-element]_ | {html}An implementation of {@link org.apache.activemq.store.PersistenceAdapter} designed for use with
+LevelDB - Embedded Lightweight Non-Relational Database{html} |
+    | _[<mKahaDB>|#mKahaDB-element]_ | {html}An implementation of {@link org.apache.activemq.store.PersistenceAdapter}  that supports
+distribution of destinations across multiple kahaDB persistence adapters{html} |
+    | _[<memoryPersistenceAdapter>|#memoryPersistenceAdapter-element]_ | {html}{html} |
+
+{anchor:org.apache.activemq.network.jms.OutboundQueueBridge-types}
+h4. The _[org.apache.activemq.network.jms.OutboundQueueBridge|#org.apache.activemq.network.jms.OutboundQueueBridge-types]_ Type Implementations
+    | _[<outboundQueueBridge>|#outboundQueueBridge-element]_ | {html}Create 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.{html} |
+
+{anchor:org.apache.activemq.broker.Locker-types}
+h4. The _[org.apache.activemq.broker.Locker|#org.apache.activemq.broker.Locker-types]_ Type Implementations
+    | _[<database-locker>|#database-locker-element]_ | {html}Represents an exclusive lock on a database to avoid multiple brokers running
+against the same logical database.{html} |
+    | _[<lease-database-locker>|#lease-database-locker-element]_ | {html}Represents an exclusive lease on a database to avoid multiple brokers running
+against the same logical database.{html} |
+    | _[<shared-file-locker>|#shared-file-locker-element]_ | {html}Represents an exclusive lock on a database to avoid multiple brokers running
+against the same logical database.{html} |
+    | _[<transact-database-locker>|#transact-database-locker-element]_ | {html}Represents an exclusive lock on a database to avoid multiple brokers running
+against the same logical database.{html} |
+
+{anchor:org.apache.activemq.broker.region.policy.MessageEvictionStrategy-types}
+h4. The _[org.apache.activemq.broker.region.policy.MessageEvictionStrategy|#org.apache.activemq.broker.region.policy.MessageEvictionStrategy-types]_ Type Implementations
+    | _[<oldestMessageEvictionStrategy>|#oldestMessageEvictionStrategy-element]_ | {html}An eviction strategy which evicts the oldest message first (which is the
+default).{html} |
+    | _[<oldestMessageWithLowestPriorityEvictionStrategy>|#oldestMessageWithLowestPriorityEvictionStrategy-element]_ | {html}An eviction strategy which evicts the oldest message with the lowest priority first.{html} |
+    | _[<uniquePropertyMessageEvictionStrategy>|#uniquePropertyMessageEvictionStrategy-element]_ | {html}An eviction strategy which evicts the oldest message within messages with the same property value{html} |
+
+{anchor:org.apache.activemq.broker.jmx.ManagementContext-types}
+h4. The _[org.apache.activemq.broker.jmx.ManagementContext|#org.apache.activemq.broker.jmx.ManagementContext-types]_ Type Implementations
+    | _[<managementContext>|#managementContext-element]_ | {html}An abstraction over JMX mbean registration{html} |
+
+{anchor:org.apache.activemq.filter.DestinationMapEntry-types}
+h4. The _[org.apache.activemq.filter.DestinationMapEntry|#org.apache.activemq.filter.DestinationMapEntry-types]_ Type Implementations
+    | _[<authorizationEntry>|#authorizationEntry-element]_ | {html}Represents 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.{html} |
+    | _[<destinationEntry>|#destinationEntry-element]_ | {html}A default entry in a DestinationMap which holds a single value.{html} |
+    | _[<filteredKahaDB>|#filteredKahaDB-element]_ | {html}{html} |
+    | _[<policyEntry>|#policyEntry-element]_ | {html}Represents an entry in a {@link PolicyMap} for assigning policies to a
+specific destination or a hierarchical wildcard area of destinations.{html} |
+    | _[<redeliveryPolicy>|#redeliveryPolicy-element]_ | {html}Configuration 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 RedeliveryPlugin{html} |
+    | _[<tempDestinationAuthorizationEntry>|#tempDestinationAuthorizationEntry-element]_ | {html}Represents an entry in a {@link DefaultAuthorizationMap} for assigning
+different operations (read, write, admin) of user roles to a temporary
+destination{html} |
+
+
+{anchor:abortSlowConsumerStrategy-element}
+h3. The _[<abortSlowConsumerStrategy>|#abortSlowConsumerStrategy-element]_ Element
+    {html}Abort slow consumers when they reach the configured threshold of slowness, default is slow for 30 seconds{html}
+h4. Properties
+    || Property Name || Type || Description ||
+    | abortConnection | _boolean_ | {html}abort the consumers connection rather than sending a stop command to the remote consumer{html} |
+    | brokerService | _[org.apache.activemq.broker.Broker|#org.apache.activemq.broker.Broker-types]_ | {html}{html} |
+    | checkPeriod | _long_ | {html}time in milliseconds between checks for slow subscriptions{html} |
+    | maxSlowCount | _long_ | {html}number of times a subscription can be deemed slow before triggering abort
+effect depends on dispatch rate as slow determination is done on dispatch{html} |
+    | maxSlowDuration | _long_ | {html}time in milliseconds that a sub can remain slow before triggering
+an abort.{html} |
+    | name | _java.lang.String_ | {html}{html} |
+
+{anchor:amqPersistenceAdapter-element}
+h3. The _[<amqPersistenceAdapter>|#amqPersistenceAdapter-element]_ Element
+    {html}An 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.{html}
+h4. Properties
+    || Property Name || Type || Description ||
+    | archiveDataLogs | _boolean_ | {html}{html} |
+    | asyncDataManager | _org.apache.activemq.kaha.impl.async.AsyncDataManager_ | {html}{html} |
+    | brokerName | _java.lang.String_ | {html}{html} |
+    | brokerService | _[org.apache.activemq.broker.BrokerService|#org.apache.activemq.broker.BrokerService-types]_ | {html}{html} |
+    | checkpointInterval | _long_ | {html}{html} |
+    | cleanupInterval | _long_ | {html}{html} |
+    | directory | _java.io.File_ | {html}{html} |
+    | directoryArchive | _java.io.File_ | {html}{html} |
+    | disableLocking | _boolean_ | {html}{html} |
+    | forceRecoverReferenceStore | _boolean_ | {html}{html} |
+    | indexBinSize | _int_ | {html}{html} |
+    | indexKeySize | _int_ | {html}{html} |
+    | indexLoadFactor | _int_ | {html}{html} |
+    | indexMaxBinSize | _int_ | {html}{html} |
+    | indexPageSize | _java.lang.String_ | {html}When set using Xbean, values of the form "20 Mb", "1024kb", and "1g" can be used{html} |
+    | journalThreadPriority | _int_ | {html}{html} |
+    | maxCheckpointMessageAddSize | _java.lang.String_ | {html}When set using Xbean, values of the form "20 Mb", "1024kb", and "1g" can be used{html} |
+    | maxFileLength | _java.lang.String_ | {html}When set using Xbean, values of the form "20 Mb", "1024kb", and "1g" can be used{html} |
+    | maxReferenceFileLength | _java.lang.String_ | {html}When set using Xbean, values of the form "20 Mb", "1024kb", and "1g" can be used{html} |
+    | persistentIndex | _boolean_ | {html}{html} |
+    | recoverReferenceStore | _boolean_ | {html}{html} |
+    | referenceStoreAdapter | _org.apache.activemq.store.ReferenceStoreAdapter_ | {html}{html} |
+    | syncOnWrite | _boolean_ | {html}{html} |
+    | taskRunnerFactory | _[org.apache.activemq.thread.TaskRunnerFactory|#org.apache.activemq.thread.TaskRunnerFactory-types]_ | {html}{html} |
+    | usageManager | _[org.apache.activemq.usage.SystemUsage|#org.apache.activemq.usage.SystemUsage-types]_ | {html}{html} |
+    | useDedicatedTaskRunner | _boolean_ | {html}{html} |
+    | useNio | _boolean_ | {html}{html} |
+    | wireFormat | _org.apache.activemq.wireformat.WireFormat_ | {html}{html} |
+
+{anchor:amqPersistenceAdapterFactory-element}
+h3. The _[<amqPersistenceAdapterFactory>|#amqPersistenceAdapterFactory-element]_ Element
+    {html}An implementation of {@link PersistenceAdapterFactory}{html}
+h4. Properties
+    || Property Name || Type || Description ||
+    | brokerName | _java.lang.String_ | {html}{html} |
+    | checkpointInterval | _long_ | {html}{html} |
+    | cleanupInterval | _long_ | {html}{html} |
+    | dataDirectory | _java.io.File_ | {html}{html} |
+    | forceRecoverReferenceStore | _boolean_ | {html}{html} |
+    | indexBinSize | _int_ | {html}{html} |
+    | indexKeySize | _int_ | {html}{html} |
+    | indexLoadFactor | _int_ | {html}{html} |
+    | indexMaxBinSize | _int_ | {html}{html} |
+    | indexPageSize | _int_ | {html}{html} |
+    | journalThreadPriority | _int_ | {html}{html} |
+    | maxFileLength | _int_ | {html}{html} |
+    | maxReferenceFileLength | _int_ | {html}{html} |
+    | persistentIndex | _boolean_ | {html}{html} |
+    | recoverReferenceStore | _boolean_ | {html}{html} |
+    | referenceStoreAdapter | _org.apache.activemq.store.ReferenceStoreAdapter_ | {html}{html} |
+    | syncOnTransaction | _boolean_ | {html}{html} |
+    | syncOnWrite | _boolean_ | {html}{html} |
+    | taskRunnerFactory | _[org.apache.activemq.thread.TaskRunnerFactory|#org.apache.activemq.thread.TaskRunnerFactory-types]_ | {html}{html} |
+    | useDedicatedTaskRunner | _boolean_ | {html}{html} |
+    | useNio | _boolean_ | {html}{html} |
+
+{anchor:authenticationUser-element}
+h3. The _[<authenticationUser>|#authenticationUser-element]_ Element
+    {html}A helper object used to configure simple authentiaction plugin{html}
+h4. Properties
+    || Property Name || Type || Description ||
+    | groups | _java.lang.String_ | {html}{html} |
+    | password | _java.lang.String_ | {html}{html} |
+    | username | _java.lang.String_ | {html}{html} |
+
+{anchor:authorizationEntry-element}
+h3. The _[<authorizationEntry>|#authorizationEntry-element]_ Element
+    {html}Represents 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.{html}
+h4. Properties
+    || Property Name || Type || Description ||
+    | admin | _java.lang.String_ | {html}{html} |
+    | adminACLs | (_java.lang.Object_)\* | {html}{html} |
+    | destination | _[org.apache.activemq.command.ActiveMQDestination|#org.apache.activemq.command.ActiveMQDestination-types]_ | {html}{html} |
+    | groupClass | _java.lang.String_ | {html}{html} |
+    | queue | _java.lang.String_ | {html}A helper method to set the destination from a configuration file{html} |
+    | read | _java.lang.String_ | {html}{html} |
+    | readACLs | (_java.lang.Object_)\* | {html}{html} |
+    | tempQueue | _boolean_ | {html}{html} |
+    | tempTopic | _boolean_ | {html}{html} |
+    | topic | _java.lang.String_ | {html}A helper method to set the destination from a configuration file{html} |
+    | write | _java.lang.String_ | {html}{html} |
+    | writeACLs | (_java.lang.Object_)\* | {html}{html} |
+
+{anchor:authorizationMap-element}
+h3. The _[<authorizationMap>|#authorizationMap-element]_ Element
+    {html}Represents 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.{html}
+h4. Properties
+    || Property Name || Type || Description ||
+    | authorizationEntries | (_java.lang.Object_)\* | {html}Sets the individual entries on the authorization map{html} |
+    | defaultEntry | _[org.apache.activemq.security.AuthorizationEntry|#org.apache.activemq.security.AuthorizationEntry-types]_ | {html}{html} |
+    | entries | (_java.lang.Object_)\* | {html}A helper method to allow the destination map to be populated from a
+dependency injection framework such as Spring{html} |
+    | tempDestinationAuthorizationEntry | _[org.apache.activemq.security.TempDestinationAuthorizationEntry|#org.apache.activemq.security.TempDestinationAuthorizationEntry-types]_ | {html}{html} |
+
+{anchor:authorizationPlugin-element}
+h3. The _[<authorizationPlugin>|#authorizationPlugin-element]_ Element
+    {html}An authorization plugin where each operation on a destination is checked
+against an authorizationMap{html}
+h4. Properties
+    || Property Name || Type || Description ||
+    | map | _[org.apache.activemq.security.AuthorizationMap|#org.apache.activemq.security.AuthorizationMap-types]_ | {html}{html} |
+
+{anchor:axionJDBCAdapter-element}
+h3. The _[<axionJDBCAdapter>|#axionJDBCAdapter-element]_ Element
+    {html}Axion 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.{html}
+h4. Properties
+    || Property Name || Type || Description ||
+    | batchStatments | _boolean_ | {html}{html} |
+    | maxRows | _int_ | {html}{html} |
+    | statements | _[org.apache.activemq.store.jdbc.Statements|#org.apache.activemq.store.jdbc.Statements-types]_ | {html}{html} |
+    | useExternalMessageReferences | _boolean_ | {html}{html} |
+
+{anchor:blobJDBCAdapter-element}
+h3. The _[<blobJDBCAdapter>|#blobJDBCAdapter-element]_ Element
+    {html}This 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:
+<ul>
+<li></li>
+</ul>{html}
+h4. Properties
+    || Property Name || Type || Description ||
+    | batchStatments | _boolean_ | {html}{html} |
+    | maxRows | _int_ | {html}{html} |
+    | statements | _[org.apache.activemq.store.jdbc.Statements|#org.apache.activemq.store.jdbc.Statements-types]_ | {html}{html} |
+    | useExternalMessageReferences | _boolean_ | {html}{html} |
+
+{anchor:broker-element}
+h3. The _[<broker>|#broker-element]_ Element
+    {html}An 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.{html}
+h4. Properties
+    || Property Name || Type || Description ||
+    | adminView | _org.apache.activemq.broker.jmx.BrokerView_ | {html}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.{html} |
+    | advisorySupport | _java.lang.String_ | {html}Allows the support of advisory messages to be disabled for performance
+reasons.{html} |
+    | allowTempAutoCreationOnSend | _boolean_ | {html}enable 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{html} |
+    | brokerContext | _org.apache.activemq.broker.BrokerContext_ | {html}{html} |
+    | brokerId | _java.lang.String_ | {html}{html} |
+    | brokerName | _java.lang.String_ | {html}Sets the name of this broker; which must be unique in the network{html} |
+    | brokerObjectName | _javax.management.ObjectName_ | {html}Sets the JMX ObjectName for this broker{html} |
+    | cacheTempDestinations | _boolean_ | {html}{html} |
+    | consumerSystemUsage | _[org.apache.activemq.usage.SystemUsage|#org.apache.activemq.usage.SystemUsage-types]_ | {html}{html} |
+    | consumerSystemUsagePortion | _int_ | {html}{html} |
+    | dataDirectory | _java.lang.String_ | {html}Sets the directory in which the data files will be stored by default for
+the JDBC and Journal persistence adaptors.{html} |
+    | dataDirectoryFile | _java.io.File_ | {html}Sets the directory in which the data files will be stored by default for
+the JDBC and Journal persistence adaptors.{html} |
+    | dedicatedTaskRunner | _boolean_ | {html}{html} |
+    | deleteAllMessagesOnStartup | _java.lang.String_ | {html}Sets whether or not all messages are deleted on startup - mostly only
+useful for testing.{html} |
+    | destinationFactory | _org.apache.activemq.broker.region.DestinationFactory_ | {html}{html} |
+    | destinationInterceptors | (_[org.apache.activemq.broker.region.DestinationInterceptor|#org.apache.activemq.broker.region.DestinationInterceptor-types]_)\* | {html}Sets the destination interceptors to use{html} |
+    | destinationPolicy | _[org.apache.activemq.broker.region.policy.PolicyMap|#org.apache.activemq.broker.region.policy.PolicyMap-types]_ | {html}Sets the destination specific policies available either for exact
+destinations or for wildcard areas of destinations.{html} |
+    | destinations | (_[org.apache.activemq.command.ActiveMQDestination|#org.apache.activemq.command.ActiveMQDestination-types]_)\* | {html}Sets the destinations which should be loaded/created on startup{html} |
+    | enableStatistics | _boolean_ | {html}Sets whether or not the Broker's services enable statistics or not.{html} |
+    | ioExceptionHandler | _[org.apache.activemq.util.IOExceptionHandler|#org.apache.activemq.util.IOExceptionHandler-types]_ | {html}override the Default IOException handler, called when persistence adapter
+has experiences File or JDBC I/O Exceptions{html} |
+    | jmsBridgeConnectors | (_[org.apache.activemq.network.jms.JmsConnector|#org.apache.activemq.network.jms.JmsConnector-types]_)\* | {html}{html} |
+    | keepDurableSubsActive | _boolean_ | {html}{html} |
+    | managementContext | _[org.apache.activemq.broker.jmx.ManagementContext|#org.apache.activemq.broker.jmx.ManagementContext-types]_ | {html}{html} |
+    | masterConnectorURI | _java.lang.String_ | {html}{html} |
+    | maxPurgedDestinationsPerSweep | _int_ | {html}{html} |
+    | mbeanInvocationTimeout | _long_ | {html}Gets the time in Milliseconds that an invocation of an MBean method will wait before
+failing.  The default value is to wait forever (zero).{html} |
+    | messageAuthorizationPolicy | _org.apache.activemq.security.MessageAuthorizationPolicy_ | {html}Sets the policy used to decide if the current connection is authorized to
+consume a given message{html} |
+    | monitorConnectionSplits | _boolean_ | {html}{html} |
+    | networkConnectorStartAsync | _boolean_ | {html}{html} |
+    | networkConnectorURIs | (_java.lang.String_)\* | {html}{html} |
+    | networkConnectors | (_[org.apache.activemq.network.NetworkConnector|#org.apache.activemq.network.NetworkConnector-types]_)\* | {html}Sets the network connectors which this broker will use to connect to
+other brokers in a federated network{html} |
+    | offlineDurableSubscriberTaskSchedule | _int_ | {html}{html} |
+    | offlineDurableSubscriberTimeout | _int_ | {html}{html} |
+    | passiveSlave | _java.lang.String_ | {html}Get the passiveSlave{html} |
+    | persistenceAdapter | _[org.apache.activemq.store.PersistenceAdapter|#org.apache.activemq.store.PersistenceAdapter-types]_ | {html}Sets the persistence adaptor implementation to use for this broker{html} |
+    | persistenceFactory | _[org.apache.activemq.store.PersistenceAdapterFactory|#org.apache.activemq.store.PersistenceAdapterFactory-types]_ | {html}{html} |
+    | persistenceTaskRunnerFactory | _[org.apache.activemq.thread.TaskRunnerFactory|#org.apache.activemq.thread.TaskRunnerFactory-types]_ | {html}{html} |
+    | persistenceThreadPriority | _int_ | {html}{html} |
+    | persistent | _java.lang.String_ | {html}Sets whether or not persistence is enabled or disabled.{html} |
+    | plugins | (_[org.apache.activemq.broker.BrokerPlugin|#org.apache.activemq.broker.BrokerPlugin-types]_)\* | {html}Sets a number of broker plugins to install such as for security
+authentication or authorization{html} |
+    | populateJMSXUserID | _boolean_ | {html}Sets whether or not the broker should populate the JMSXUserID header.{html} |
+    | populateUserNameInMBeans | _boolean_ | {html}Should MBeans that support showing the Authenticated User Name information have this
+value filled in or not.{html} |
+    | producerSystemUsage | _[org.apache.activemq.usage.SystemUsage|#org.apache.activemq.usage.SystemUsage-types]_ | {html}{html} |
+    | producerSystemUsagePortion | _int_ | {html}{html} |
+    | proxyConnectors | (_java.lang.Object_)\* | {html}Sets the network connectors which this broker will use to connect to
+other brokers in a federated network{html} |
+    | regionBroker | _[org.apache.activemq.broker.Broker|#org.apache.activemq.broker.Broker-types]_ | {html}{html} |
+    | schedulePeriodForDestinationPurge | _int_ | {html}{html} |
+    | schedulerDirectory | _java.lang.String_ | {html}{html} |
+    | schedulerDirectoryFile | _java.io.File_ | {html}{html} |
+    | schedulerSupport | _java.lang.String_ | {html}{html} |
+    | services | (_[org.apache.activemq.Service|#org.apache.activemq.Service-types]_)\* | {html}Sets the services associated with this broker such as a
+{@link MasterConnector}{html} |
+    | shutdownHooks | (_java.lang.Object_)\* | {html}Sets hooks to be executed when broker shut down{html} |
+    | shutdownOnMasterFailure | _boolean_ | {html}{html} |
+    | shutdownOnSlaveFailure | _java.lang.String_ | {html}{html} |
+    | splitSystemUsageForProducersConsumers | _boolean_ | {html}{html} |
+    | sslContext | _[org.apache.activemq.broker.SslContext|#org.apache.activemq.broker.SslContext-types]_ | {html}{html} |
+    | start | _boolean_ | {html}Sets 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.{html} |
+    | startAsync | _boolean_ | {html}{html} |
+    | supportFailOver | _boolean_ | {html}{html} |
+    | systemExitOnShutdown | _java.lang.String_ | {html}{html} |
+    | systemExitOnShutdownExitCode | _int_ | {html}{html} |
+    | systemUsage | _[org.apache.activemq.usage.SystemUsage|#org.apache.activemq.usage.SystemUsage-types]_ | {html}{html} |
+    | taskRunnerFactory | _[org.apache.activemq.thread.TaskRunnerFactory|#org.apache.activemq.thread.TaskRunnerFactory-types]_ | {html}{html} |
+    | taskRunnerPriority | _int_ | {html}{html} |
+    | tempDataStore | _[org.apache.activemq.store.kahadb.plist.PListStore|#org.apache.activemq.store.kahadb.plist.PListStore-types]_ | {html}{html} |
+    | timeBeforePurgeTempDestinations | _int_ | {html}{html} |
+    | tmpDataDirectory | _java.io.File_ | {html}{html} |
+    | transportConnectorURIs | (_java.lang.String_)\* | {html}{html} |
+    | transportConnectors | (_[org.apache.activemq.broker.TransportConnector|#org.apache.activemq.broker.TransportConnector-types]_)\* | {html}Sets the transport connectors which this broker will listen on for new
+clients{html} |
+    | useAuthenticatedPrincipalForJMSXUserID | _boolean_ | {html}{html} |
+    | useJmx | _java.lang.String_ | {html}Sets whether or not the Broker's services should be exposed into JMX or
+not.{html} |
+    | useLocalHostBrokerName | _boolean_ | {html}{html} |
+    | useLoggingForShutdownErrors | _boolean_ | {html}Sets whether or not we should use commons-logging when reporting errors
+when shutting down the broker{html} |
+    | useMirroredQueues | _boolean_ | {html}Sets whether or not <a
+href="http://activemq.apache.org/mirrored-queues.html">Mirrored
+Queues</a> should be supported by default if they have not been
+explicitly configured.{html} |
+    | useShutdownHook | _boolean_ | {html}Sets 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.{html} |
+    | useTempMirroredQueues | _boolean_ | {html}{html} |
+    | useVirtualTopics | _boolean_ | {html}Sets whether or not <a
+href="http://activemq.apache.org/virtual-destinations.html">Virtual
+Topics</a> should be supported by default if they have not been
+explicitly configured.{html} |
+    | vmConnectorURI | _java.net.URI_ | {html}{html} |
+    | waitForSlave | _java.lang.String_ | {html}{html} |
+    | waitForSlaveTimeout | _long_ | {html}{html} |
+
+{anchor:brokerService-element}
+h3. The _[<brokerService>|#brokerService-element]_ Element
+    {html}Manages the lifecycle 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.{html}
+h4. Properties
+    || Property Name || Type || Description ||
+    | adminView | _org.apache.activemq.broker.jmx.BrokerView_ | {html}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.{html} |
+    | advisorySupport | _java.lang.String_ | {html}Allows the support of advisory messages to be disabled for performance
+reasons.{html} |
+    | allowTempAutoCreationOnSend | _boolean_ | {html}enable 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{html} |
+    | brokerContext | _org.apache.activemq.broker.BrokerContext_ | {html}{html} |
+    | brokerId | _java.lang.String_ | {html}{html} |
+    | brokerName | _java.lang.String_ | {html}Sets the name of this broker; which must be unique in the network{html} |
+    | brokerObjectName | _javax.management.ObjectName_ | {html}Sets the JMX ObjectName for this broker{html} |
+    | cacheTempDestinations | _boolean_ | {html}{html} |
+    | consumerSystemUsage | _[org.apache.activemq.usage.SystemUsage|#org.apache.activemq.usage.SystemUsage-types]_ | {html}{html} |
+    | consumerSystemUsagePortion | _int_ | {html}{html} |
+    | dataDirectory | _java.lang.String_ | {html}Sets the directory in which the data files will be stored by default for
+the JDBC and Journal persistence adaptors.{html} |
+    | dataDirectoryFile | _java.io.File_ | {html}Sets the directory in which the data files will be stored by default for
+the JDBC and Journal persistence adaptors.{html} |
+    | dedicatedTaskRunner | _boolean_ | {html}{html} |
+    | deleteAllMessagesOnStartup | _java.lang.String_ | {html}Sets whether or not all messages are deleted on startup - mostly only
+useful for testing.{html} |
+    | destinationFactory | _org.apache.activemq.broker.region.DestinationFactory_ | {html}{html} |
+    | destinationInterceptors | (_[org.apache.activemq.broker.region.DestinationInterceptor|#org.apache.activemq.broker.region.DestinationInterceptor-types]_)\* | {html}Sets the destination interceptors to use{html} |
+    | destinationPolicy | _[org.apache.activemq.broker.region.policy.PolicyMap|#org.apache.activemq.broker.region.policy.PolicyMap-types]_ | {html}Sets the destination specific policies available either for exact
+destinations or for wildcard areas of destinations.{html} |
+    | destinations | (_[org.apache.activemq.command.ActiveMQDestination|#org.apache.activemq.command.ActiveMQDestination-types]_)\* | {html}Sets the destinations which should be loaded/created on startup{html} |
+    | enableStatistics | _boolean_ | {html}Sets whether or not the Broker's services enable statistics or not.{html} |
+    | ioExceptionHandler | _[org.apache.activemq.util.IOExceptionHandler|#org.apache.activemq.util.IOExceptionHandler-types]_ | {html}override the Default IOException handler, called when persistence adapter
+has experiences File or JDBC I/O Exceptions{html} |
+    | jmsBridgeConnectors | (_[org.apache.activemq.network.jms.JmsConnector|#org.apache.activemq.network.jms.JmsConnector-types]_)\* | {html}{html} |
+    | keepDurableSubsActive | _boolean_ | {html}{html} |
+    | managementContext | _[org.apache.activemq.broker.jmx.ManagementContext|#org.apache.activemq.broker.jmx.ManagementContext-types]_ | {html}{html} |
+    | masterConnectorURI | _java.lang.String_ | {html}{html} |
+    | maxPurgedDestinationsPerSweep | _int_ | {html}{html} |
+    | mbeanInvocationTimeout | _long_ | {html}Gets the time in Milliseconds that an invocation of an MBean method will wait before
+failing.  The default value is to wait forever (zero).{html} |
+    | messageAuthorizationPolicy | _org.apache.activemq.security.MessageAuthorizationPolicy_ | {html}Sets the policy used to decide if the current connection is authorized to
+consume a given message{html} |
+    | monitorConnectionSplits | _boolean_ | {html}{html} |
+    | networkConnectorStartAsync | _boolean_ | {html}{html} |
+    | networkConnectorURIs | (_java.lang.String_)\* | {html}{html} |
+    | networkConnectors | (_[org.apache.activemq.network.NetworkConnector|#org.apache.activemq.network.NetworkConnector-types]_)\* | {html}Sets the network connectors which this broker will use to connect to
+other brokers in a federated network{html} |
+    | offlineDurableSubscriberTaskSchedule | _int_ | {html}{html} |
+    | offlineDurableSubscriberTimeout | _int_ | {html}{html} |
+    | passiveSlave | _java.lang.String_ | {html}Get the passiveSlave{html} |
+    | persistenceAdapter | _[org.apache.activemq.store.PersistenceAdapter|#org.apache.activemq.store.PersistenceAdapter-types]_ | {html}Sets the persistence adaptor implementation to use for this broker{html} |
+    | persistenceFactory | _[org.apache.activemq.store.PersistenceAdapterFactory|#org.apache.activemq.store.PersistenceAdapterFactory-types]_ | {html}{html} |
+    | persistenceTaskRunnerFactory | _[org.apache.activemq.thread.TaskRunnerFactory|#org.apache.activemq.thread.TaskRunnerFactory-types]_ | {html}{html} |
+    | persistenceThreadPriority | _int_ | {html}{html} |
+    | persistent | _java.lang.String_ | {html}Sets whether or not persistence is enabled or disabled.{html} |
+    | plugins | (_[org.apache.activemq.broker.BrokerPlugin|#org.apache.activemq.broker.BrokerPlugin-types]_)\* | {html}Sets a number of broker plugins to install such as for security
+authentication or authorization{html} |
+    | populateJMSXUserID | _boolean_ | {html}Sets whether or not the broker should populate the JMSXUserID header.{html} |
+    | populateUserNameInMBeans | _boolean_ | {html}Should MBeans that support showing the Authenticated User Name information have this
+value filled in or not.{html} |
+    | producerSystemUsage | _[org.apache.activemq.usage.SystemUsage|#org.apache.activemq.usage.SystemUsage-types]_ | {html}{html} |
+    | producerSystemUsagePortion | _int_ | {html}{html} |
+    | proxyConnectors | (_java.lang.Object_)\* | {html}Sets the network connectors which this broker will use to connect to
+other brokers in a federated network{html} |
+    | regionBroker | _[org.apache.activemq.broker.Broker|#org.apache.activemq.broker.Broker-types]_ | {html}{html} |
+    | schedulePeriodForDestinationPurge | _int_ | {html}{html} |
+    | schedulerDirectory | _java.lang.String_ | {html}{html} |
+    | schedulerDirectoryFile | _java.io.File_ | {html}{html} |
+    | schedulerSupport | _java.lang.String_ | {html}{html} |
+    | services | (_[org.apache.activemq.Service|#org.apache.activemq.Service-types]_)\* | {html}Sets the services associated with this broker such as a
+{@link MasterConnector}{html} |
+    | shutdownHooks | (_java.lang.Object_)\* | {html}Sets hooks to be executed when broker shut down{html} |
+    | shutdownOnMasterFailure | _boolean_ | {html}{html} |
+    | shutdownOnSlaveFailure | _java.lang.String_ | {html}{html} |
+    | splitSystemUsageForProducersConsumers | _boolean_ | {html}{html} |
+    | sslContext | _[org.apache.activemq.broker.SslContext|#org.apache.activemq.broker.SslContext-types]_ | {html}{html} |
+    | startAsync | _boolean_ | {html}{html} |
+    | supportFailOver | _boolean_ | {html}{html} |
+    | systemExitOnShutdown | _java.lang.String_ | {html}{html} |
+    | systemExitOnShutdownExitCode | _int_ | {html}{html} |
+    | systemUsage | _[org.apache.activemq.usage.SystemUsage|#org.apache.activemq.usage.SystemUsage-types]_ | {html}{html} |
+    | taskRunnerFactory | _[org.apache.activemq.thread.TaskRunnerFactory|#org.apache.activemq.thread.TaskRunnerFactory-types]_ | {html}{html} |
+    | taskRunnerPriority | _int_ | {html}{html} |
+    | tempDataStore | _[org.apache.activemq.store.kahadb.plist.PListStore|#org.apache.activemq.store.kahadb.plist.PListStore-types]_ | {html}{html} |
+    | timeBeforePurgeTempDestinations | _int_ | {html}{html} |
+    | tmpDataDirectory | _java.io.File_ | {html}{html} |
+    | transportConnectorURIs | (_java.lang.String_)\* | {html}{html} |
+    | transportConnectors | (_[org.apache.activemq.broker.TransportConnector|#org.apache.activemq.broker.TransportConnector-types]_)\* | {html}Sets the transport connectors which this broker will listen on for new
+clients{html} |
+    | useAuthenticatedPrincipalForJMSXUserID | _boolean_ | {html}{html} |
+    | useJmx | _java.lang.String_ | {html}Sets whether or not the Broker's services should be exposed into JMX or
+not.{html} |
+    | useLocalHostBrokerName | _boolean_ | {html}{html} |
+    | useLoggingForShutdownErrors | _boolean_ | {html}Sets whether or not we should use commons-logging when reporting errors
+when shutting down the broker{html} |
+    | useMirroredQueues | _boolean_ | {html}Sets whether or not <a
+href="http://activemq.apache.org/mirrored-queues.html">Mirrored
+Queues</a> should be supported by default if they have not been
+explicitly configured.{html} |
+    | useShutdownHook | _boolean_ | {html}Sets 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.{html} |
+    | useTempMirroredQueues | _boolean_ | {html}{html} |
+    | useVirtualTopics | _boolean_ | {html}Sets whether or not <a
+href="http://activemq.apache.org/virtual-destinations.html">Virtual
+Topics</a> should be supported by default if they have not been
+explicitly configured.{html} |
+    | vmConnectorURI | _java.net.URI_ | {html}{html} |
+    | waitForSlave | _java.lang.String_ | {html}{html} |
+    | waitForSlaveTimeout | _long_ | {html}{html} |
+
+{anchor:bytesJDBCAdapter-element}
+h3. The _[<bytesJDBCAdapter>|#bytesJDBCAdapter-element]_ Element
+    {html}This JDBCAdapter inserts and extracts BLOB data using the
+setBytes()/getBytes() operations. The databases/JDBC drivers that use this
+adapter are:{html}
+h4. Properties
+    || Property Name || Type || Description ||
+    | batchStatments | _boolean_ | {html}{html} |
+    | maxRows | _int_ | {html}{html} |
+    | statements | _[org.apache.activemq.store.jdbc.Statements|#org.apache.activemq.store.jdbc.Statements-types]_ | {html}{html} |
+    | useExternalMessageReferences | _boolean_ | {html}{html} |
+
+{anchor:cachedLDAPAuthorizationMap-element}
+h3. The _[<cachedLDAPAuthorizationMap>|#cachedLDAPAuthorizationMap-element]_ Element
+    {html}A {@link DefaultAuthorizationMap} implementation which uses LDAP to initialize and update authorization
+policy.{html}
+h4. Properties
+    || Property Name || Type || Description ||
+    | adminPermissionGroupSearchFilter | _java.lang.String_ | {html}{html} |
+    | authentication | _java.lang.String_ | {html}{html} |
+    | authorizationEntries | (_java.lang.Object_)\* | {html}Sets the individual entries on the authorization map{html} |
+    | connectionPassword | _java.lang.String_ | {html}{html} |
+    | connectionProtocol | _java.lang.String_ | {html}{html} |
+    | connectionURL | _java.lang.String_ | {html}{html} |
+    | connectionUsername | _java.lang.String_ | {html}{html} |
+    | defaultEntry | _[org.apache.activemq.security.AuthorizationEntry|#org.apache.activemq.security.AuthorizationEntry-types]_ | {html}{html} |
+    | entries | (_java.lang.Object_)\* | {html}A helper method to allow the destination map to be populated from a
+dependency injection framework such as Spring{html} |
+    | groupNameAttribute | _java.lang.String_ | {html}{html} |
+    | groupObjectClass | _java.lang.String_ | {html}{html} |
+    | legacyGroupMapping | _boolean_ | {html}{html} |
+    | permissionGroupMemberAttribute | _java.lang.String_ | {html}{html} |
+    | queueSearchBase | _java.lang.String_ | {html}{html} |
+    | readPermissionGroupSearchFilter | _java.lang.String_ | {html}{html} |
+    | refreshDisabled | _boolean_ | {html}{html} |
+    | refreshInterval | _int_ | {html}{html} |
+    | tempDestinationAuthorizationEntry | _[org.apache.activemq.security.TempDestinationAuthorizationEntry|#org.apache.activemq.security.TempDestinationAuthorizationEntry-types]_ | {html}{html} |
+    | tempSearchBase | _java.lang.String_ | {html}{html} |
+    | topicSearchBase | _java.lang.String_ | {html}{html} |
+    | userNameAttribute | _java.lang.String_ | {html}{html} |

[... 2630 lines stripped ...]