Tuning Guide
Optimize Red Hat JBoss A-MQ for your environment
Copyright © 2011-2015 Red Hat, Inc. and/or its affiliates.
Abstract
Chapter 1. Introduction to Performance Tuning
Limiting factors
- The speed at which messages are written to and read from disk (persistent brokers only).
- The speed at which messages can be marshalled and sent over the network.
- Context switching, due to multi-threading.
Non-persistent and persistent brokers
Broker networks
Chapter 2. General Tuning Techniques
Abstract
2.1. System Environment
Overview
Disk speed
Network performance
Hardware specification
Memory available to the JVM
-Xmx
option. For example, to increase JVM memory to 2048 MB, add -Xmx2048M
(or equivalently, -Xmx2G
) as a JVM option.
2.2. Co-locating the Broker
Overview
vm://
transport.
Figure 2.1. Broker Co-located with Producer
data:image/s3,"s3://crabby-images/8b8fb/8b8fb37f83702c81fc19b3d83b5c17b402787402" alt="Broker Co-located with Producer"
The vm:// transport
vm://
endpoint from a producer or a consumer in just the same way as you connect to a tcp://
endpoint (or any other protocol supported by Red Hat JBoss A-MQ). But the effect of connecting to a vm://
endpoint is quite different from connecting to a tcp://
endpoint: whereas a tcp://
endpoint initiates a connection to a remote broker instance, the vm://
endpoint actually creates a local, embedded broker instance. The embedded broker runs inside the same JVM as the client and messages are sent to the broker through an internal channel, bypassing the network.
vm://brokerName
brokerConfig
option. For example, to create a myBroker
instance that takes its configuration from the activemq.xml
configuration file, define the following VM endpoint:
vm://myBroker?brokerConfig=xbean:activemq.xml
A simple optimization
vm://brokerName?async=false
optimizedDispatch
, and the consumer option, dispatchAsync
, are also configured to disable asynchronous behaviour, the calling thread can actually dispatch directly to consumers.
2.3. Optimizing the Protocols
Overview
TCP transport
- Socket buffer size—the default TCP socket buffer size is 64 KB. While this is adequate for the speed of networks in use at the time TCP was originally designed, this buffer size is sub-optimal for modern high-speed networks. The following rule of thumb can be used to estimate the optimal TCP socket buffer size:Buffer Size = Bandwidth x Round-Trip-TimeWhere the Round-Trip-Time is the time between initially sending a TCP packet and receiving an acknowledgement of that packet (ping time). Typically, it is a good idea to try doubling the socket buffer size to 128 KB. For example:
tcp://hostA:61617?socketBufferSize=131072
For more details, see the Wikipedia article on Network Improvement. - I/O buffer size—the I/O buffer is used to buffer the data flowing between the TCP layer and the protocol that is layered above it (such as OpenWire). The default I/O buffer size is 8 KB and you could try doubling this size to achieve better performance. For example:
tcp://hostA:61617?ioBufferSize=16384
OpenWire protocol
Parameter | Default | Description |
---|---|---|
cacheEnabled | true | Specifies whether to cache commonly repeated values, in order to optimize marshaling. |
cacheSize | 1024 | The number of values to cache. Increase this value to improve performance of marshaling. |
tcpNoDelayEnabled | false | When true , disable the Nagles algorithm. The Nagles algorithm was devised to avoid sending tiny TCP packets containing only one or two bytes of data; for example, when TCP is used with the Telnet protocol. If you disable the Nagles algorithm, packets can be sent more promptly, but there is a risk that the number of very small packets will increase. |
tightEncodingEnabled | true | When true , implement a more compact encoding of basic data types. This results in smaller messages and better network performance, but comes at a cost of more calculation and demands made on CPU time. A trade off is therefore required: you need to determine whether the network or the CPU is the main factor that limits performance. |
wireFormat.
prefix. For example, to double the size of the OpenWire cache, you can specify the cache size on a URI as follows:
tcp://hostA:61617?wireFormat.cacheSize=2048
Enabling compression
useCompression
option on the ActiveMQConnectionFactory
class. For example, to initialize a JMS connection with compression enabled in a Java client, insert the following code:
// Java
...
// Create the connection.
ActiveMQConnectionFactory connectionFactory = new ActiveMQConnectionFactory(user, password, url);
connectionFactory.setUseCompression(true);
Connection connection = connectionFactory.createConnection();
connection.start();
jms.useCompression
option on a producer URI—for example:
tcp://hostA:61617?jms.useCompression=true
2.4. Message Encoding
Message body type
StreamMessage
MapMessage
TextMessage
ObjectMessage
BytesMessage
BytesMessage
(a stream of uninterpreted bytes) is the fastest, while ObjectMessage
(serialization of a Java object) is the slowest.
Encoding recommendation
BytesMessage
whenever possible. We suggest that you use Google's Protobuf, which has excellent performance characteristics.
2.5. Threading Optimizations
Optimized dispatch
optimizedDispatch
option to true
on all queue destinations. When this option is enabled, the broker no longer uses a dedicated thread to dispatch messages to each destination.
optimizedDispatch
option on all queue destinations, insert the following policy entry into the broker configuration:
<broker ... >
<destinationPolicy>
<policyMap>
<policyEntries>
<policyEntry queue=">" optimizedDispatch=”true” />
</policyEntries>
</policyMap>
</destinationPolicy>
...
</broker>
queue
attribute, >
, is a wildcard that matches all queue names.
2.6. Vertical Scaling
Definition
Tricks to optimize vertical scaling
- NIO transport on the broker—to reduce the number of threads required, use the NIO transport (instead of the TCP transport) when defining transport connectors in the broker. Do not use the NIO transport in clients, it is only meant to be used in the broker.
- Allocate more memory to broker—to increase the amount of memory available to the broker, pass the
-Xmx
option to the JVM. - Reduce initial thread stack size—to allocate a smaller initial stack size for threads, pass the
-Xss
option to the JVM.
2.7. Horizontal Scaling
Overview
Figure 2.2. Scaling with Multiple Brokers
data:image/s3,"s3://crabby-images/8a70e/8a70e3b7fa4a7371f9ab910380eff79797307b5b" alt="Scaling with Multiple Brokers"
Broker networks
Static scales better than dynamic
Asynchronous network connection establishment
networkConnectorStartAsync
attribute on the broker
element to true
, as follows:
<beans ...>
<broker ... networkConnectorStartAsync="true">...</broker>
</beans>
Client-side traffic partitioning
- You can use all the tuning techniques for vertical scaling.
- You can achieve better horizontal scalability than a network of brokers (because there is less broker crosstalk).
2.8. Integration with Spring and Camel
Overview
JmsTemplate
, which allows you to hide some of the lower level JMS details when sending messages and so on. One thing to bear in mind about JmsTemplate
, however, is that it creates a new connection, session, and producer for every message it sends, which is very inefficient. It is implemented like this in order to work inside an EJB container, which typically provides a special JMS connection factory that supports connection pooling.
org.apache.activemq.pool.PooledConnectionFactory
, from the activemq-pool
artifact, which pools JMS resources to work efficiently with Spring's JmsTemplate
or with EJBs.
Creating a pooled connection factory
PooledConnectionFactory
is implemented as a wrapper class that is meant to be chained with another connection factory instance. For example, you could use a PooledConnectionFactory
instance to wrap a plain Red Hat JBoss A-MQ connection factory, or to wrap an ActiveMQSslConnectionFactory
, and so on.
Example
jmsFactory
, that works efficiently with the Spring JmsTemplate
instance, myJmsTemplate
, define the following bean instances in your Spring configuration file:
<!-- A pooling-based JMS provider --> <bean id="jmsFactory" class="org.apache.activemq.pool.PooledConnectionFactory" destroy-method="stop"> <property name="connectionFactory"> <bean class="org.apache.activemq.ActiveMQConnectionFactory"> <property name="brokerURL"> <value>tcp://localhost:61616</value> </property> </bean> </property> </bean> <!-- Spring JMS Template --> <bean id="myJmsTemplate" class="org.springframework.jms.core.JmsTemplate"> <property name="connectionFactory"> <ref local="jmsFactory"/> </property> </bean>
ActiveMQConnectionFactory
instance that opens connections to the tcp://localhost:61616
broker endpoint.
2.9. Optimizing Memory Usage in the Broker
Optimize message paging
policyEntry
element, you can tune the message paging to match the amount of memory available in the broker. For example, if there is very large queue and lots of destination memory, increasing the maxBrowsePage
attribute would allow more of those messages to be visible when browsing a queue.
Destination policies to control paging
maxPageSize
- The maximum number of messages paged into memory for sending to a destination.
maxBrowsePageSize
- NoteThe number of messages paged in for browsing cannot exceed the destination's
memoryLimit
setting. maxExpirePageSize
- The maximum number of messages paged into memory to check for expired messages.
2.10. Optimizing JMX Management
Selective MBean registration
<managementContext> <managementContext suppressMBean="endpoint=dynamicProducer,endpoint=Consumer,connectionName=*,destinationName=ActiveMQ.Advisory.*" /> </managementContext>
Chapter 3. Consumer Performance
3.1. Acknowledgement Modes
Overview
Supported acknowledgement modes
Session.AUTO_ACKNOWLEDGE
- (Default) In this mode, the JMS session automatically acknowledges messages as soon as they are received. In particular, the JMS session acknowledges messages before dispatching them to the application layer. For example, if the consumer application calls
MessageConsumer.receive()
, the message has already been acknowledged before the call returns. Session.CLIENT_ACKNOWLEDGE
- In this mode, the client application code explicitly calls the
Message.acknowledge()
method to acknowledge the message. In Apache Camel, this acknowledges not just the message on which it is invoked, but also any other messages in the consumer that have already been completely processed. Session.DUPS_OK_ACKNOWLEDGE
- In this mode, the JMS session automatically acknowledges messages, but does so in a lazy manner. If JMS fails while this mode is used, some messages that were completely processed could remain unacknowledged. When JMS is restarted, these messages will be re-sent (duplicate messages).This is one of the fastest acknowledgement modes, but the consumer must be able to cope with possible duplicate messages (for example, by detecting and discarding duplicates).
Session.SESSION_TRANSACTED
- When using transactions, the session implicitly works in
SESSION_TRANSACTED
mode. The response to the transaction commit is then equivalent to message acknowledgement.When JMS transactions are used to group multiple messages, transaction mode is very efficient. But avoid using a transaction to send a single message, because this incurs the extra overhead of committing or rolling back the transaction. ActiveMQSession.INDIVIDUAL_ACKNOWLEDGE
- This non-standard mode is similar to
CLIENT_ACKNOWLEDGE
, except that it acknowledges only the message on which it is invoked. It does not flush acknowledgements for any other completed messages.
optimizeAcknowledge option
optimizeAcknowledge
option is exposed on the ActiveMQConnectionFactory
class and must be used in conjunction with the Session.AUTO_ACKNOWLEDGE
mode. When set to true
, the consumer acknowledges receipt of messages in batches, where the batch size is set to 65% of the prefetch limit. Alternatively, if message consumption is slow, the batch acknowledgement will be sent after 300ms. Default is false
.
tcp://hostA:61617?jms.optimizeAcknowledge=true
optimizeAcknowledge
option is only supported by the JMS client API.
Choosing the acknowledgement mode
DUPS_OK_ACKNOWLEDGE
mode, which requires you to implement duplicate detection code in your consumer.
3.2. Reducing Context Switching
Overview
Optimize message dispatching on the broker side
consumer.dispatchAsync
option to false
on the transport URI used by the consumer. For example, to disable asynchronous dispatch to the TEST.QUEUE
queue, use the following URI on the consumer side:
TEST.QUEUE?consumer.dispatchAsync=false
dispatchAsync
property to false on the ActiveMQ connection factory—for example:
// Java ((ActiveMQConnectionFactory)connectionFactory).setDispatchAsync(false);
Optimize message reception on the consumer side
Session
threads and the MessageConsumer
threads. In the special case where only one session is associated with a connection, the two layers are redundant and it is possible to optimize the threading model by eliminating the thread associated with the session layer. This section explains how to enable this consumer threading optimization.
Default consumer threading model
javax.jms.Session
instance. The second thread layer consists of a pool of threads, where each thread is associated with a javax.jms.MessageConsumer
instance. Each thread in this layer picks the relevant messages out of the session queue, inserting each message into a queue inside the javax.jms.MessageConsumer
instance.
Figure 3.1. Default Consumer Threading Model
data:image/s3,"s3://crabby-images/ee877/ee877bf34924fcb603799bcc81844a82b06cfde3" alt="Default Consumer Threading Model"
Optimized consumer threading model
MessageConsumer
threads can then pull messages directly from the transport layer.
Figure 3.2. Optimized Consumer Threading Model
data:image/s3,"s3://crabby-images/f661f/f661f56f7a87bfce401dc7186b4df4a97b0783e9" alt="Optimized Consumer Threading Model"
Prerequisites
- There must only be one JMS session on the connection. If there is more than one session, a separate thread is always used for each session, irrespective of the value of the
alwaysSessionAsync
flag. - One of the following acknowledgement modes must be selected:
Session.DUPS_OK_ACKNOWLEDGE
Session.AUTO_ACKNOWLEDGE
alwaysSessionAsync option
alwaysSessionAsync
option to false
on the ActiveMQConnectionFactory
(default is true
).
optimizeAcknowledge
option is only supported by the JMS client API.
Example
alwaysSessionAsync
flag:
// Java ... // Create the connection. ActiveMQConnectionFactory connectionFactory = new ActiveMQConnectionFactory(user, password, url); connectionFactory.setAlwaysSessionAsync(false); Connection connection = connectionFactory.createConnection(); connection.start(); // Create the one-and-only session on this connection. Session session = connection.createSession(false, Session.AUTO_ACKNOWLEDGE);
3.3. Prefetch Limit
Overview
Prefetch limits
- Queue consumer
- Default prefetch limit is 1000.If you are using a collection of consumers to distribute the workload (many consumers processing messages from the same queue), you typically want this limit to be small. If one consumer is allowed to accumulate a large number of unacknowledged messages, it could starve the other consumers of messages. Also, if the consumer fails, there would be a large number of messages unavailable for processing until the failed consumer is restored.
- Queue browser
- Default prefetch limit is 500.
- Topic consumer
- Default prefetch limit is 32766.The default limit of 32766 is the largest value of a short and is the maximum possible value of the prefetch limit.
- Durable topic subscriber
- Default prefetch limit is 100.You can typically improve the efficiency of a consumer by increasing this prefetch limit.
Optimizing prefetch limits
- Queue consumers—if you have just a single consumer attached to a queue, you can leave the prefetch limit at a fairly large value. But if you are using a group of consumers to distribute the workload, it is usually better to restrict the prefetch limit to a very small number—for example, 0 or 1.
- Durable topic subscribers—the efficiency of topic subscribers is generally improved by increasing the prefetch limit. Try increasing the limit to 1000.
Chapter 4. Producer Performance
4.1. Async Sends
Overview
Configuring on a transport URI
jms.useAsyncSend
option to true
on the transport URI that you use to connect to the broker. For example:
tcp://locahost:61616?jms.useAsyncSend=true
Configuring on a connection factory
useAsyncSend
property to true
directly on the ActiveMQConnectionFactory
instance. For example:
// Java ((ActiveMQConnectionFactory)connectionFactory).setUseAsyncSend(true);
Configuring on a connection
useAsyncSend
property to true
directly on the ActiveMQConnection
instance. For example:
// Java ((ActiveMQConnection)connection).setUseAsyncSend(true);
4.2. Flow Control
Overview
Flow control enabled
Figure 4.1. Broker with Flow Control Enabled
data:image/s3,"s3://crabby-images/0018e/0018eb9819f4d2042832fc93526ee9b3d4724f06" alt="Broker with Flow Control Enabled"
Flow control disabled
Figure 4.2. Broker with Flow Control Disabled
data:image/s3,"s3://crabby-images/47f4b/47f4bbb4760ce2130a16f201ed7e8e18198d8fcf" alt="Broker with Flow Control Disabled"
Discarding messages
PRICES.>
pattern (that is, topic names prefixed by PRICES.
), configure the broker as follows:
<beans ... > <broker ...> <!-- lets define the dispatch policy --> <destinationPolicy> <policyMap> <policyEntries> <policyEntry topic="PRICES.>"> <!-- lets force old messages to be discarded for slow consumers --> <pendingMessageLimitStrategy> <constantPendingMessageLimitStrategy limit="10"/> </pendingMessageLimitStrategy> </policyEntry> ... </policyEntries> </policyMap> </destinationPolicy> </broker> </beans>
How to turn off flow control
producerFlowControl
attribute to false
on a policyEntry
element.
FOO.
, insert a policy entry like the following into the broker's configuration:
<broker ... > ... <destinationPolicy> <policyMap> <policyEntries> <policyEntry topic="FOO.>" producerFlowControl="false"/> ... </policyEntries> </policyMap> </destinationPolicy> ... </broker>
Defining the memory limits
- Per-broker—to set global memory limits on a broker, define a
systemUsage
element as a child of thebroker
element, as follows:<broker> ... <systemUsage> <systemUsage> <memoryUsage> <memoryUsage limit="64 mb" /> </memoryUsage> <storeUsage> <storeUsage limit="100 gb" /> </storeUsage> <tempUsage> <tempUsage limit="10 gb" /> </tempUsage> </systemUsage> </systemUsage> ... </broker>
Where the preceding sample specifies three distinct memory limits, as follows:memoryUsage
—specifies the maximum amount of memory allocated to the broker.storeUsage
—for persistent messages, specifies the maximum disk storage for the messages.NoteIn certain scenarios, the actual disk storage used by JBoss A-MQ can exceed the specified limit. For this reason, it is recommended that you setstoreUsage
to about 70% of the intended maximum disk storage.tempUsage
—for temporary messages, specifies the maximum amount of memory.
The values shown in the preceding example are the defaults. - Per-destination—to set a memory limit on a destination, set the
memoryLimit
attribute on thepolicyEntry
element. The value ofmemoryLimit
can be a string, such as10 MB
or512 KB
. For example, to limit the amount of memory on theFOO.BAR
queue to 10 MB, define a policy entry like the following:<policyEntry queue="FOO.BAR" memoryLimit="10 MB"/>
Making a producer aware of flow control
send()
operation to block, until enough memory is freed up in the broker for the producer to resume sending messages. If you want the producer to be made aware of the fact that the send()
operation is blocked due to flow control, you can enable either of the following attributes on the systemUsage
element:
sendFailIfNoSpace
- If
true
, the broker immediately returns an error when flow control is preventing producersend()
operations; otherwise, revert to default behaviour. sendFailIfNoSpaceAfterTimeout
- Specifies a timeout in units of milliseconds. When flow control is preventing producer
send()
operations, the broker returns an error, after the specified timeout has elapsed.
send()
operations:
<broker>
...
<systemUsage>
<systemUsage sendFailIfNoSpace="true">
<memoryUsage>
<memoryUsage limit="64 mb" />
</memoryUsage>
...
</systemUsage>
</systemUsage>
...
</broker>
Chapter 5. Managing Slow Consumers
Overview
- limiting the number of messages retained for a consumerWhen using non-durable topics, you can specify the number of messages that a destination will hold for a consumer. Once the limit is reached, older messages are discarded when new messages arrive.
- aborting slow consumersJBoss A-MQ determines slowness by monitoring how often a consumer's dispatch buffer is full. You can specify that consistently slow consumers be aborted by closing its connection to the broker.
Limiting message retention
pendingMessageLimitStrategy
) on a topic to control the number of messages that are held for slow consumers. When set, the topic will retain the specified number of messages in addition to the consumer's prefetch limit.
-1
, which means that the topic will retain all of the unconsumed messages for a consumer.
- specifying a constant number of messages over the prefetch limitThe
constantPendingMessageLimitStrategy
implementation allows you to specify constant number of messages to retain as shown in Example 5.1, “Constant Pending Message Limiter”.Example 5.1. Constant Pending Message Limiter
<broker ... > <destinationPolicy> <policyMap> <policyEntries> <policyEntry topic=">" > <pendingMessageLimitStrategy> <constantPendingMessageLimitStrategy limit="50"/> </pendingMessageLimitStrategy> </policyEntry> </policyEntries> </policyMap> </destinationPolicy> ... </broker>
- specifying a multiplier that is applied to the prefetch limitThe
prefetchRatePendingMessageLimitStrategy
implementation allows you to specify a multiplier that is applied to the prefect limit. Example 5.2, “Prefectch Limit Based Pending Message Limiter” shown configuration that retains twice the prefect limit. So if the prefect limit is 3, the destination will retain 6 pending messages for each consumer.Example 5.2. Prefectch Limit Based Pending Message Limiter
<broker ... > <destinationPolicy> <policyMap> <policyEntries> <policyEntry topic=">" > <pendingMessageLimitStrategy> <prefetchRatePendingMessageLimitStrategy multiplier="2"/> </pendingMessageLimitStrategy> </policyEntry> </policyEntries> </policyMap> </destinationPolicy> ... </broker>
Aborting slow consumers
- a consumer is considered slow for specified amount of time
- a consumer is considered slow a specified number of times
Example 5.3. Aborting Slow Consumers
<broker ... > ... <destinationPolicy> <policyMap> <policyEntries> <policyEntry topic=">" > <slowConsumerStrategy> <abortSlowConsumerStrategy /> </slowConsumerStrategy> </policyEntry> </policyEntries> </policyMap> </destinationPolicy> ... </broker>
abortSlowConsumerStrategy
element activates the abort slow consumer strategy with default settings. Consumers that are considered slow for more than 30 seconds are aborted. You can modify when slow consumers are aborted using the attributes described in Table 5.1, “Settings for Abort Slow Consumer Strategy”.
Attribute | Default | Description |
---|---|---|
maxSlowCount | -1 | Specifies the number of times a consumer can be considered slow before it is aborted. -1 specifies that a consumer can be considered slow an infinite number of times. |
maxSlowDuration | 30000 | Specifies the maximum amount of time, in milliseconds, that a consumer can be continuously slow before it is aborted. |
checkPeriod | 30000 | Specifies, in milliseconds, the time between checks for slow consumers. |
abortConnection | false | Specifies whether the broker forces the consumer connection to close. The default value specifies that the broker will send a message to the consumer requesting it to close its connection. true specifies that the broker will automatically close the consumer's connection. |
Example 5.4. Aborting Repeatedly Slow Consumers
<abortSlowConsumerStrategy maxSlowCount="30" />
Chapter 6. Persistent Messaging
Abstract
6.1. Serializing to Disk
KahaDB message store
Synchronous dispatch through a persistent broker
Figure 6.1. Synchronous Dispatch through a Persistent Broker
data:image/s3,"s3://crabby-images/3791a/3791a2e13604fd6b4a9d969ee388a75385dd9fa9" alt="Synchronous Dispatch through a Persistent Broker"
- The broker pushes the message into the message store. Assuming that the
enableJournalDiskSyncs
option istrue
, the message store also writes the message to disk, before the broker proceeds. - The broker now sends the message to all of the interested consumers (but does not wait for consumer acknowledgements). For topics, the broker dispatches the message immediately, while for queues, the broker adds the message to a destination cursor.
- The broker then sends a receipt back to the producer. The receipt can thus be sent back before the consumers have finished acknowledging messages (in the case of topic messages, consumer acknowledgements are usually not required anyway).
Concurrent store and dispatch
Figure 6.2. Concurrent Store and Dispatch
data:image/s3,"s3://crabby-images/0488d/0488ddab569b08adfb0c629e86f2ca73374454a9" alt="Concurrent Store and Dispatch"
- The broker pushes the message onto the message store and, concurrently, sends the message to all of the interested consumers. After sending the message to the consumers, the broker then sends a receipt back to the producer, without waiting for consumer acknowledgements or for the message store to synchronize to disk.
- As soon as the broker receives acknowledgements from all the consumers, the broker removes the message from the message store. Because consumers typically acknowledge messages faster than a message store can write them to disk, this often means that write to disk is optimized away entirely. That is, the message is removed from the message store before it is ever physically written to disk.
Configuring concurrent store and dispatch
concurrentStoreAndDispatchQueues
flag and the concurrentStoreAndDispatchTopics
flag. By default, it is enabled for queues, but disabled for topics. To enable concurrent store and dispatch for both queues and topics, configure the kahaDB
element in the broker configuration as follows:
<broker brokerName="broker" persistent="true" useShutdownHook="false"> ... <persistenceAdapter> <kahaDB directory="activemq-data" journalMaxFileLength="32mb" concurrentStoreAndDispatchQueues="true" concurrentStoreAndDispatchTopics="true" /> </persistenceAdapter> </broker>
Reducing memory footprint of pending messages
reduceMemoryFootprint
option, as follows:
<broker ... > ... <destinationPolicy> <policyMap> <policyEntries> <policyEntry queue=">" reduceMemoryFootprint="true" /> </policyEntries> </policyMap> </destinationPolicy> ... </broker>
reduceMemoryFootprint
option is enabled, a message's marshalled content is cleared immediately after the message is written to persistent storage. This results in approximately a 50% reduction in the amount of memory occupied by the pending messages.
6.2. KahaDB Optimization
Overview
KahaDB architecture
Figure 6.3. KahaDB Architecture
data:image/s3,"s3://crabby-images/bfdac/bfdac78b795df3282b62b04646b4b9d6713088c6" alt="KahaDB Architecture"
Sample configuration
persistenceAdapter
element containing a kahaDB
child element:
<broker brokerName="broker" persistent="true" useShutdownHook="false">
...
<persistenceAdapter>
<kahaDB directory="activemq-data" journalMaxFileLength="32mb"/>
</persistenceAdapter>
</broker>
directory
property specifies the directory where the KahaDB files are stored and the journalMaxFileLength
specifies the maximum size of a data log file.
Performance optimization
kahaDB
element):
indexCacheSize
—(default10000
) specifies the size of the cache in units of pages (where one page is 4 KB by default). Generally, the cache should be as large as possible, to avoid swapping pages in and out of memory. Check the size of your metadata store file,db.data
, to get some idea of how big the cache needs to be.indexWriteBatchSize
—(default1000
) defines the threshold for the number of dirty indexes that are allowed to accumulate, before KahaDB writes the cache to the store. If you want to maximize the speed of the broker, you could set this property to a large value, so that the store is updated only during checkpoints. But this carries the risk of losing a large amount of metadata, in the event of a system failure (causing the broker to restart very slowly).journalMaxFileLength
—(default32mb
) when the throughput of a broker is very large, you can fill up a journal file quite quickly. Because there is a cost associated with closing a full journal file and opening a new journal file, you can get a slight performance improvement by increasing the journal file size, so that this cost is incurred less frequently.enableJournalDiskSyncs
—(defaulttrue
) normally, the broker performs a disk sync (ensuring that a message has been physically written to disk) before sending the acknowledgement back to a producer. You can obtain a substantial improvement in broker performance by disabling disk syncs (setting this property tofalse
), but this reduces the reliability of the broker somewhat.WarningIf you need to satisfy the JMS durability requirement and be certain that you do not lose any messages, do not disable journal disk syncs.
Optimizing disk syncs
fdatasync()
system call instead of the fsync()
system call (the default), when writing to a file. The difference between these system calls is that fdatasync()
updates only the file data, whereas fsync()
updates both the file data and the file metadata (for example, the access time).
etc/system.properties
file in your JBoss A-MQ installation:
org.apache.activemq.kahaDB.files.skipMetadataUpdate=true
fdatasync()
system call. When this option is enabled, the JBoss A-MQ runtime actually makes a call to java.nio.channels.FileChannel#force=false
. For some JVMs, this can result in a call to fdatasync()
(so that the optimization is effective), but with other JVMs it might be implemented using fsync()
(so that the optimization has no effect).
fsync()
on RHEL 6 is noticeably slower than on RHEL 4 (this is due to a bug fix in RHEL 6). So, this optimization works particularly well on the RHEL 6 platform, where fdatasync()
is significantly faster.
6.3. vmCursor on Destination
Overview
Configuring destinations to use the vmCursor
vmCursor
for all topics and queues, add the following lines to your broker configuration:
<broker ... > ... <destinationPolicy> <policyMap> <policyEntries> <policyEntry topic=">"> <pendingSubscriberPolicy> <vmCursor /> </pendingSubscriberPolicy> </policyEntry> <policyEntry queue=">"> <deadLetterStrategy> <individualDeadLetterStrategy queuePrefix="Test.DLQ."/> </deadLetterStrategy> <pendingQueuePolicy> <vmQueueCursor /> </pendingQueuePolicy> </policyEntry> </policyEntries> </policyMap> </destinationPolicy> ... </broker>
>
, that matches all destination names. You could also specify a more selective destination pattern, so that the VM cursor would be enabled only for those destinations where you are sure that consumers can keep up with the message flow.
Reference
6.4. JMS Transactions
Improving efficiency using JMS transactions
Legal Notice
Trademark Disclaimer