Apache ActiveMQ Changelog

What's new in Apache ActiveMQ 5.18.2

Jul 3, 2023
  • Fix potential NPE when removing consumer with selector
  • Fix composite consumers in a Network of Brokers
  • Fix memory leak on the STOMP transport when client unsubscribe
  • A bunch of dependency updates

New in Apache ActiveMQ 5.18.1 (Apr 15, 2023)

  • Fixed:
  • JmsConnector handling loss of connection.

New in Apache ActiveMQ 5.18.0 (Mar 26, 2023)

  • Apache ActiveMQ 5.18.0 was released on Mar 24th, 2023. It’s a major milestone for the ActiveMQ project. ActiveMQ 5.18.x brings:
  • JMS2 compliant clients, with one client using javax.jms namespacee and one clieent using jakarta.jms namespace (see JMS v2.0 page)
  • Spring 5.3.x
  • Optimized LDAP use in LDAP JAAS login module
  • Improved REST API
  • Improved redelivery policy
  • A lot of dependency updates
  • And much more!

New in Apache ActiveMQ 5.17.4 (Feb 26, 2023)

  • Sub-task:
  • [AMQ-9208] - Upgrade xstream to 1.4.20
  • [AMQ-9209] - Upgrade commons-daemon to 1.3.3
  • [AMQ-9210] - Upgrade ant to 1.10.13
  • [AMQ-9211] - Upgrade shiro to 1.11.0
  • [AMQ-9212] - Upgrade jettison to 1.5.3
  • [AMQ-9213] - Upgrade regex to jakarta-regexp 1.4
  • [AMQ-9214] - Upgrade httpclient to 4.5.14
  • [AMQ-9215] - Upgrade httpcore to 4.4.16
  • Bug:
  • [AMQ-9185] - java.lang.NullPointerException: Cannot invoke "String.length()" because "replacement" is null
  • [AMQ-9192] - Fix flaky AdvisoryTests causing CI failures
  • [AMQ-9193] - Improve broker shutdown logic in unit tests to improve test reliability
  • [AMQ-9196] - ActiveMQ jar bundled with Xsteam library is vulnerable which should upgrade to Xstream 1.4.20 (CVE-2022-41966)
  • [AMQ-9199] - Race condition in creating store directory for new queues
  • [AMQ-9202] - Reentrant locks should always be locked outside of a try block
  • Improvement:
  • [AMQ-9201] - Update Jolokia default access configuration
  • [AMQ-9217] - Fix per-destination audits on IndividualDeadLetterStrategy
  • Dependency upgrade:
  • [AMQ-9176] - Upgrade to Apache POM 28
  • [AMQ-9195] - Upgrade XStream to 1.4.20 - CVE-2022-41966
  • [AMQ-9197] - Prototype Javascript Framework - CVE-2020-27511
  • [AMQ-9204] - Upgrade to jetty 9.4.50.v20221201
  • [AMQ-9205] - Upgrade to jackson 2.14.2
  • [AMQ-9206] - Upgrade to Spring 5.3.25
  • [AMQ-9207] - Upgrade various dependencies

New in Apache ActiveMQ 5.16.4 (Feb 15, 2022)

  • Bug:
  • [AMQ-5388] - User Role Granted Full Privileges in jetty.xml
  • [AMQ-7340] - Scheduled messages performance degrade
  • [AMQ-8093] - Illegal reflective access by IntrospectionSupport
  • [AMQ-8252] - Unnecessary stack trace in case of invalid credentials
  • [AMQ-8253] - Unnecessary stack trace in case of invalid STOMP version
  • [AMQ-8275] - Java 16 SSL connection gives an error in the log
  • [AMQ-8383] - ActiveMQ status command - 5.16.2 version
  • [AMQ-8395] - NPE on Topic SlowConsumerAdvisory
  • [AMQ-8400] - ConcurrentModificationException in Transaction.java
  • [AMQ-8409] - Unexpected \r instead of r in header property in incoming messages
  • [AMQ-8425] - Linux start script doesn't work depending of ps command version
  • [AMQ-8439] - Validate example camel.xml fails in the assembly
  • [AMQ-8445] - Several tests are failing in activemq-stomp due to SecurityException
  • New Feature:
  • [AMQ-8372] - Provide possiblity to enter delimiter when sending TextMessage via MBean
  • Improvement:
  • [AMQ-8053] - Don't override JMSXUserId when message comes across network connector
  • [AMQ-8397] - Add SendDuplicateFromStoreToDLQ flag to Destination
  • [AMQ-8412] - Return a well-formed response to clients when max message size is sent
  • [AMQ-8413] - Support different username and password for remote broker
  • [AMQ-8443] - Fix FailoverTransport to honor ConnectionControl reconnect
  • [AMQ-8462] - Remove double call to listConnectionStates during connection close
  • [AMQ-8468] - CVE-2022-23437: Infinite loop within Apache XercesJ xml parser
  • [AMQ-8472] - Switch to reload4j for logging
  • Task:
  • [AMQ-7351] - Update to Apache POM 24
  • [AMQ-8362] - Update Jenkinsfile to -fae for tests
  • Dependency upgrade:
  • [AMQ-8358] - Upgrade xstream to 1.4.18
  • [AMQ-8359] - Upgrade slf4j to 1.7.32
  • [AMQ-8360] - Upgrade to Apache Commons Pool 2.11.1
  • [AMQ-8393] - Upgrade to jackson 2.12.5
  • [AMQ-8394] - Upgrade to shiro 1.8.0
  • [AMQ-8396] - Upgrade to jaxb-basics 0.12.0
  • [AMQ-8404] - Upgrade to jackson 2.13.0
  • [AMQ-8405] - Upgrade to ASM 9.2
  • [AMQ-8410] - Update to Guava 31.0.1
  • [AMQ-8428] - Upgrade to httpcore 4.4.15
  • [AMQ-8467] - Upgrade to xstream 1.4.19

New in Apache ActiveMQ 5.15.9 (Mar 26, 2019)

  • Apache ActiveMQ 5.15.9 includes several resolved issues and bug fixes.

New in Apache ActiveMQ 5.15.9 (Mar 26, 2019)

  • Apache ActiveMQ 5.15.9 includes several resolved issues and bug fixes.

New in Apache ActiveMQ 5.15.4 (May 23, 2018)

  • Bug:
  • [AMQ-6901] - Destination with wildcard may not have correct policy applied if multiple wildcard policies exist
  • [AMQ-6924] - StoreDurableSubscriberCursor does not timeout properly on non-persistent message send
  • [AMQ-6940] - Significant memory footprint increase from 5.8.0 to 5.15.3
  • Improvement;
  • [AMQ-6934] - Update Jackson to latest version
  • [AMQ-6935] - Update Jolokia to 1.5.0
  • [AMQ-6958] - AMQP: Set a default maxFrameSize for AMQP connections
  • [AMQ-6959] - Avoid creating a Throwable in case of non-trace logging
  • [AMQ-6962] - Update Spring framework version

New in Apache ActiveMQ 5.15.3 (Feb 6, 2018)

  • Bug:
  • [AMQ-6327] - getNextScheduledTime() returns incorrect time when working with day of month
  • [AMQ-6601] - AMQ with master and slave broker, shutting down slave causes dead-lock
  • [AMQ-6815] - KahaDB checkpoint needs to fail fast in the event of journal write failure
  • [AMQ-6847] - Immediate poison ACK after move from DLQ leads to message loss
  • [AMQ-6858] - Fix several durable subscription bridge propagation issues
  • [AMQ-6871] - ActiveMQ client should send only generic platform details by default to server
  • [AMQ-6875] - Virtual destination consumers can create invalid demand for Virtual Topics
  • Improvement:
  • [AMQ-6828] - Improvement to python AMQP example
  • [AMQ-6861] - Allow customisation of network bridge creation logic
  • [AMQ-6872] - AMQP: Use proper typing when accessing ApplicationProperties Map values
  • [AMQ-6884] - NIO SelectorWorker should use logger instead of printStackTrace
  • Task:
  • [AMQ-6856] - AMQP: Update Qpid JMS to latest 0.27.0 release and Proton-j to 0.23.0 to match
  • [AMQ-6874] - AMQP: Update Qpid JMS to latest 0.29.0 release and Proton-j to 0.25.0 to match
  • Edit/Copy Release Notes

New in Apache ActiveMQ 5.15.2 (Dec 12, 2017)

  • Bug:
  • [AMQ-6831] - Broker fails to start complaining about missing/corrupt journal files after upgrading to 5.15.1
  • [AMQ-6834] - ClassNotFoundException when install activemq-osgi bundle with Camel 2.19.x into OSGi container
  • Task:
  • [AMQ-6830] - AMQP: Update Qpid JMS to latest 0.26.0 release and match its netty version 4.1.16.Final

New in Apache ActiveMQ 5.10.1 (Jan 22, 2015)

  • Bug:
  • [AMQ-5032] - AMQP Message Expiry Time not mapped correctly in many case to / from JMS
  • [AMQ-5043] - Improve MQTT spec compatibility
  • [AMQ-5086] - vm transport create=false&waitForStart race condition
  • [AMQ-5125] - Broker and clients hang
  • [AMQ-5198] - MessageConsumer and Producer are not thread safe
  • [AMQ-5211] - ActiveMQDestination.createDestination() should prevent empty destination name
  • [AMQ-5212] - Deadlock with duplicate detection and dlq processing in kahadb
  • [AMQ-5220] - Advisory messages are still empty when received with a Stomp subscription
  • [AMQ-5223] - activemq-jms-pool is missing OSGi metadata
  • [AMQ-5226] - When create on start is set to true, the JMS Pool can return the same connection twice in a row
  • [AMQ-5241] - Spurious WARN FailoverTransport - Transport .. failed, reason: , attempting to automatically reconnect java.io.EOFException
  • [AMQ-5251] - Scheduler missing some synchronization
  • [AMQ-5256] - AMQP WARN Transport Connection failed: java.io.IOException
  • [AMQ-5258] - Connection reference leak in PooledConnectionFactory leading to expired connections stuck in the pool
  • [AMQ-5262] - ActiveMQ hangs on shutdown when JMS Bridge is created
  • [AMQ-5265] - JMX destination entires fail due to race condition in MBeanBridgeDestination
  • [AMQ-5268] - PooledConnectionFactory gets in endless loop when storing into JNDI
  • [AMQ-5277] - JDBC ack does not use messageId.entryLocator
  • [AMQ-5279] - failover redelivery to alternative consumers with pending transaction causes rollback *and* dlq processing
  • [AMQ-5295] - HTTPS Network Connector doesn't work with Mutual authentication- HTTPSClientTransport uses wrong SSLSocketFactory
  • [AMQ-5304] - groupClass not applied to TempDestinationAuthorizationEntry
  • [AMQ-5315] - NullPointerException in DemandForwardingBridgeSupport.collectBrokerInfos
  • [AMQ-5323] - ActiveMQ Message getProperty and setProperty inconsistent behaviour
  • [AMQ-5337] - Bug in ConcurrentLinkedQueue leads to excessive CPU-consumption by ActiveMQ process
  • [AMQ-5345] - Improve LDAP communication
  • [AMQ-5381] - ActiveMQBytesMessage mishandles restoration of old message contents
  • [AMQ-5514] - Create Release 5.10.1
  • Improvement:
  • [AMQ-5015] - Temp Queue gets deleted on close of wrong connection
  • [AMQ-5214] - Security errors for sync commands are only logged at debug levels
  • [AMQ-5231] - Failover Transport timeout option causes connection failures in some cases where it shouldn't
  • [AMQ-5239] - Enable access to BrokerService instances
  • [AMQ-5289] - Track forwards across a network in destination statistics
  • [AMQ-5292] - Add support for publishing to MQTT '$' Topics (that start with the prefix '$')
  • Task:
  • [AMQ-5309] - Backport - Close connections when the connector is stopped.

New in Apache ActiveMQ 5.10.0 (Jun 11, 2014)

  • Fixes and improvements:
  • MQTT Hierarchical Destination names may start with a leading '/', which must be ignored when mapping to ActiveMQ destination name
  • Improve performance of virtual topic fanout and persistent asyncSend
  • Web Console - java.lang.OutOfMemoryError: Java heap space - while browsing deep queues
  • Dispatching large messages over AMQP is very slow.
  • MQTT server connections are not thread safe
  • Upgrade Camel to latest 2.12.x patch
  • Messages stuck and never gets processed
  • Queue Messages lost after read timeout on REST API.
  • LevelDB corrupted when in a replication cluster
  • Session.commit() hangs when amqp+nio is used
  • JMSClientNioTest fails intermittently
  • Session.commit() hangs when amqp+nio+ssl is used
  • Old Web Admin console does not manage - new parameter messageTTL consumerTTL connections.jsp and connections Panel display error messages
  • Wildcard subscriptions bypass Authentication / Authorization
  • Pending Queue Counter is incorrect when using durable topics
  • MQTT unit tests fail
  • './bin/activemq console' should 'exec' java so that way scripts calling it can get the pid for the broker's java process.
  • Enable "Link Stealing" as an option on a Connector
  • 64-bit Java wrapper ignores wrapper.java.maxmemory values over 4096mb
  • Qpid producer.send with sync_publish=true set against activemq blocks and doesn't return
  • runtime config - add support for spring properties config with properties or bean factory
  • runtime config - namespace prefix causes npe on config load
  • add 'stop' goal to the maven-activemq-plugin
  • Allow getJMSRedelivered flag to survive a restart
  • Broker doesn't stop using the activemq script if the JMX port is changed
  • Journaled JDBC checkpoint fails with java.io.IOException: Already started.
  • Look at the possibility of incorporating a cassandra persistence adapter from http://github.com/ticktock/qsandra
  • Tomcat support in ActiveMQ
  • JMS Stream may lost data
  • ActiveMQResourceAdapter.getXARessources() broken
  • Persisted messages reappear after broker restart when using amqp
  • Messages stuck in queue with redelivered=true
  • ActiveMQ does not work on Karaf 3
  • JMS queue browser returns only page size number of messages
  • include activemq-jms-pool in activemq-all
  • StatisticsPlugin - destination stats should include broker info
  • kahadb - do some sanity check on the index when checkForCorruptJournalFiles
  • runtime config - embed spring beans schema to avoid trip to the internet in osgi land
  • jdbc ioexception handler can restart transports in error after lease expriy
  • ActiveMQ should depend to http feature instead of jetty
  • Replicated LevelDB: Loss of broker Quorum fails to fully stop the master
  • AmqpErrorException occurs with multiple concurrent amqp topic consumers
  • Add JMX stats for Consumers and Producers accessible from the Broker
  • AMQP consumer hangs when receiving large messages
  • " java.lang.ClassCastException: org.apache.activemq.command.ExceptionResponse cannot be cast to org.apache.activemq.command.IntegerResponse, attempting to automatically reconnect"
  • Karaf commands should auto-export interfaces
  • java.lang.OutOfMemoryError: Java heap space Exception when sending big amount(1000+) of 1M non persistent messages to broker
  • Duplicate messages are left in the persistence store
  • JDBCPersistenceAdapter: queue messages trapped in store when DB connection is lost and restored
  • Race condition in failover transport
  • MQTT does not properly restore durable subs with the Paho client.
  • ActiveMQBytesMessage will lost content if message's property was set before copy
  • Wildcard matches do not match
  • ActiveMQ client loses connectivity and admin interface is corrupted after being up for ~60 hours
  • ProxyConnector memory usage skyrockets when several ssl handshakes fails
  • Bug in the WebConsole RemoteJMX connectivity
  • Put back Jolokia management API
  • Runtime Configuration Plugin - reapply destination interceptor after reload
  • Better protect worker thread in TcpTransportServer that handles socket accepts
  • lease-database-locker does not use the configured tablePrefix in UPDATE statement
  • Invalid STOMP frame sent on websocket connections with heartbeats.
  • deprecated JMS streams
  • Unable to create the native threads while using apache activemq
  • Broker limits store space, not taking into account what it's already using
  • Advisory support leads to excessive CPU usage
  • Show clientId view of duplex network connection Mbeans
  • activemq-unit-tests - A test keep failing testVirtualTopicFailover
  • runtime config - support modifications to simpleAuthenticationPlugin plugin
  • Provide more granular karaf features
  • runtime config - support addition of composite virtual destinations - forwardTo
  • JMSClientTest is hanging
  • RAR - Active session can delay/block endpoint deactivation on shutdown
  • webconsole url and html encoding missing
  • embedded webconsole broker does not resolve activemq.data system property
  • Remove jetty and jsp compiler jars from web-console.war
  • Using maven-eclipse-plugin to generate eclipse projects fails for leveldb
  • Update QPid client to v0.26
  • Upgrade to xstream 1.4.7
  • The first packet from client to Broker MUST be a CONNECT packet, Broker MUST disconnect when UNSUBSCRIBE is the first packet
  • Broker MUST respond with CONNACK with return code 0x02 for zero length client id and 0 cleansession
  • MQTTInactivityMonitor throws a NullPointerException
  • Populate a 'Host' header in the WireFormatInfo of the Openwire protocol to let multi-tenant proxies route connections
  • Set headless when running tests.
  • Display the number of active transactions and age of oldest transaction on a Connection's JMX info
  • deleting durable subscriber exception
  • Maven version affects packaging
  • Support hardening/persisting the JMSRedeliveryFlag across restarts
  • Duplicate MQTT Subscription with a different QoS for the same Topic MUST remove the older Subscription
  • MQTT Retained message QoS must be set to a maximum of Subscription's QoS
  • RedeliveryPolicy redeliveryDelay is ignored if initialRedeliveryDelay is specified
  • MQTT paths with empty levels are not handled correctly
  • Support configuring a different directory for the KahaDB index files.
  • AMQP Transport throws unauthorized access for all error that occur during a connection attempt
  • Pooled session creation blocks when maxActive is reached
  • Broker should stop accepting work when trying to shut down transports
  • Improve Failover transport transaction tracking
  • Upgrade to jolokia 1.2
  • RAR - missing messages on master slave failover
  • MQTT uses duplicate packet IDs for PUBLISH messages
  • AMQP: If a proton client only sets the ttl, and not the message timestamp, ActiveMQ does not handle the expiration correctly
  • RestPersistentTest sometimes hangs on CI boxes
  • Eclipse build with latest Scala plugins fails
  • On overlapping Failover a session can consume large amounts of memory trying to clear consumer state.
  • AMQP producers aren't removed
  • Fix destination statistics queue name
  • STOMP browse gets null pointer exception if ACK mode is not AUTO
  • Multiple tests using durable subs are failing
  • stomp+nio+ssl very slow message sending
  • RedeliveryPolicy exceeded for crashing consumer
  • Message expiry that is done as part of a removeSubscription command should not use the clients credentials.
  • ArithmeticException: / by zero in HealthView.healthList() when using JMX-Health-Operations
  • Potential deadlock
  • broker redeliveryPlugin: after message redelivery, all subsequent "producer.send()" using same message are "scheduled" for delivery to queue rather than delivered to queue as normal
  • Optionally support encrypted passwords in ActiveMQ users.properties file.
  • MemoryUsage is not decremented on a JMS topic when rolling back a transacted session
  • Add roundrip amqp send/receive sanity to karaf-itest for osgi validation
  • Add proton META_INF/services to the activemq-osgi bundle definition so AMQP works inside Karaf
  • Provide SSL_OPTS to all tasks in shell scripts
  • No disposition set on Discharge response for AMQP TX commit or rollback
  • In-flight queue message redelivered to multiple listeners upon broker shutdown
  • unable to build trunk from scratch due to missing dependency
  • MQTT SUBACK packet MUST use return code 0x80 to report failed topic subscriptions
  • batchStatment is misspelled for JDBC adaptors
  • AbortSlowAckConsumerStrategy with abortConnection=false; ensure consumers are always removed from the broker
  • AMQP Protocol doesn't send back meaningfull errors for unauthroized access
  • Uber JAR with source code should be in apache-activemq and we only need a single zip file
  • Slave broker does not shutdown after persistence store lockout.
  • Memory leak in ConnectionStateTracker when browsing non-empty queues
  • heart-beat is disabled when connecting to web socket
  • Rollback on XASession when closing back to pool
  • Connections not closing on AMQP connector when client closes its side.
  • Java Files Started Appearing in activemq-all jar starting in 5.9.0
  • ActiveMQ web-cosole fails to start in Karaf - missing import
  • Ignored InterruptedException in IdGenerator
  • activemq-camel should explicitly Import-Package org.apache.activemq.pool
  • clients can not receive mqtt retained message
  • advisory producerCount = 0 is not received on temporary queue
  • Extends activemq-karaf import version range to work with both Karaf 2 & 3
  • LevelDB store can fail when using durable subs
  • OSGi granularity of activemq-osgi bundle
  • Added JMX metics for networks per destination
  • camel doen't honor credentials set on activemqcomponent bean via spring
  • jdbcPersistenceAdapter takes a long time to shutdown, causing journal recovery
  • Kahadb error during SAN failover delayed write - Allow kahaDB to recover in a similar manner as the JDBC store using the IOExceptionHandler
  • PooledConnectionFactoryBean returns null in OSGi env sometimes
  • Http/https protocol uses Xstream for serializing commands in xml. Field additions to the commands bresks xtream serializacion between amq versions
  • Show flow control being active on web console ...
  • Failover transport - Add option to configure WARN logging internval for failover attempts still failing
  • ConnectionFactory and ActiveMQCamelComponent should default to the right port if on OpenShift
  • DynamicallyIncludedDestinationsDuplexNetworkTest.testDynamicallyIncludedDestinationsForDuplex fails on EC2 boxes
  • NetworkConnector not registered in JMX when created from Broker View
  • When duplicate message occur from network producer, messages blocked by cursor audit are blocked till restart
  • Reduce the reliance on fsync when writing to disk
  • UTF8Buffer should be a valid object for setObjectProperty
  • WSServlet.doWebSocketConnect throws NPE if called with null protocol
  • Fusesource release repo not needed
  • MQTT clients disconnecting due to socket error do not publish the configured last will and testament message.
  • Deletion of a queue inaffective across broker restart
  • REST API MessageServlet does not accept JSON or plain text content types in request
  • LDAPLoginModule throws InvalidNameException when resolving LDAP aliases
  • REST API only accepts non-form content if content type of text/xml
  • Enable amqp transport out of the box in activemq-karaf
  • activemq:dstat - Sort list of queues/topics by default
  • ActiveMQ old web console in Karaf 2.3 fails sending to queues due karaf security
  • Chat demo - May cause NPE when disconnecting clients
  • Update deprecated code in activemq-camel tests
  • webconsole - Viewing message details when message ID contains a plus results in " No message could be found for ID {messageID}"
  • Upgrade to xstream 1.4.5
  • Add connection counters at broker level
  • Applet ClassLoader Problems
  • Avoid unnecessary remainder operator for floating-point
  • Reducing memory usage should log at INFO/WARN level instead of ERROR
  • activemq:dstat command can throw error for topic subscriptions views
  • Bug in web console
  • JmsRollbackRedeliveryTest.testRedeliveryWithPrefetch1 fails intermittently
  • Documentation on integration with spring contains misleading part regarding embedded broker
  • Issues in password encryption
  • XPath selectors return false if xalan is not on the classpath
  • Default the ServerUrl to vm://brokerName?create=false when an embedded broker is specified with brokerXmlConfig
  • improve logging configuration for broker & examples
  • Race condition in org.apache.activemq.util.osgi.Activator
  • Problem with servicing broker messages when client hostName contains "language specific" characters (org.apache.activemq.util.IdGenerator problem)
  • Make registering of custom BlobUploader and BlobDownloader more easy
  • Socket parameters are not validated
  • activemq-maven-plugin should have a stop goal
  • Memory Leak for ActiveMQBytesMessage with Compression as true
  • Adding a retry-button
  • Deleting/moving a message from queue overview should redirect back to overview of the queue
  • Windows batch script doesn't like spaces in installation path
  • Is it hawtio ui bug?
  • Add new mode to JMS Pool that allows for not caching producers
  • Multiple consumers of the same virtual topic queue cannot have different message selectors
  • Typos in MessageStore
  • DurableSubscriptionOfflineTest.testOrderOnActivateDeactivate fails on CI boxes
  • Wrong JMX object name created in RemoteJMXBrokerFacade
  • Change MIME type for XML in the REST API
  • Typos in SubscriptionInfo
  • Align xbean and upgrade to 3.15
  • Update the JobSchedulerStoreImpl in KahaDB to use LockableServiceSupport
  • Possible case of curroption in Scheduler store
  • Remove NetworkConnectionsCleanedupTest?
  • FailoverConsumerTest.testPublisherFailsOver is failing
  • JoramJmsNioTest hangs intermittently
  • Unable to install the feature activemq-blueprint in Karaf 2.3.3
  • Average message size attribute on broker mbean should not have decimals
  • Allow isSameRM override from broker identity to connection identity to avoid xa.join
  • DemandForwardingBridgeSupport has noisy log
  • Inflight Count for topics is not correct
  • Wrong or incomplete log message in PooledTaskRunner class.
  • Disable jar indexing
  • org.apache.activemq.bugs.MemoryUsageBlockResumeTest sometimes hangs
  • ActiveMQPrefetchPolicy.setAll sets inputStreamPrefetch incorrectly
  • JmsSendReceiveTwoConnectionsWithSenderUsingPoolTest.testSendReceive fails with NPE in PooledProducer
  • Upgrade Proton to v0.6
  • ActiveMQ Web Console URL log message hard coded to localhost
  • Switch to using Proton's Event logic for detecting AMQP state changes
  • exclude bouncycastle dependency from unit tests run
  • Boreker configured as zeroconf service is not discovered by Bonjour browser running in ios
  • MessageDatabase does not consistently apply tracker settings
  • Enable durable topic subscriptions using individual ack mode.
  • Unnecessary log of Stacktrace within DiscoveryNetworkConnector
  • Useless code in VMTransport class
  • Show non-durable Topic subscriptions on the web console
  • HSQLDB support is broken as wrong data type is used in HsqldbJDBCAdapter.java
  • AMQP protocol handler doesn't set session incoming capacity
  • Add additional properties to advisory for consumed, delivered and discarded
  • amq.js initHandler() method swallows first message received
  • ActiveMQ configuration.
  • The examples/swissarmy should setup slf4j/log4j when running
  • Scala source file forgotten in /src/main/java
  • Typos in stomp/ProtocolConverter.java
  • Statistics plugin doesn't fill in Message timestamp or priority

New in Apache ActiveMQ 5.9.1 (Apr 15, 2014)

  • New features:
  • Replicated LevelDB Store for shared nothing Master/Slave.
  • Runtime Configuration
  • Hawtio web console
  • Generic JMS XA connection pool in activemq-jms-pool module (has no ActiveMQ dependency)
  • MQTT over WebSockets support
  • broker Apache Camel component
  • Broker auto-restart upon losing master status
  • AMQP Hardening
  • LevelDB Hardening
  • Bug fixes:
  • Web Console - java.lang.OutOfMemoryError: Java heap space - while browsing deep queues
  • LevelDB corrupted when in a replication cluster
  • Old Web Admin console does not manage - new parameter messageTTL consumerTTL connections.jsp and connections Panel display error messages
  • Session.commit() hangs when amqp+nio is used
  • Queue Messages lost after read timeout on REST API.
  • Invalid STOMP frame sent on websocket connections with heartbeats.
  • Broker limits store space, not taking into account what it's already using
  • NetworkConnector not registered in JMX when created from Broker View
  • runtime config - namespace prefix causes npe on config load
  • JMS queue browser returns only page size number of messages
  • Broker should stop accepting work when trying to shut down transports
  • Improve Failover transport transaction tracking
  • RedeliveryPolicy redeliveryDelay is ignored if initialRedeliveryDelay is specified
  • Maven version affects packaging
  • Display the number of active transactions and age of oldest transaction on a Connection's JMX info
  • JMSClientTest is hanging
  • Remove jetty and jsp compiler jars from web-console.war
  • RAR - Active session can delay/block endpoint deactivation on shutdown
  • embedded webconsole broker does not resolve activemq.data system property
  • webconsole url and html encoding missing
  • RestPersistentTest sometimes hangs on CI boxes
  • AMQP: If a proton client only sets the ttl, and not the message timestamp, ActiveMQ does not handle the expiration correctly
  • Runtime Configuration Plugin - reapply destination interceptor after reload
  • ActiveMQResourceAdapter.getXARessources() broken
  • On overlapping Failover a session can consume large amounts of memory trying to clear consumer state.
  • MQTT unit tests fail
  • Deletion of a queue inaffective across broker restart
  • Memory leak in ConnectionStateTracker when browsing non-empty queues
  • When duplicate message occur from network producer, messages blocked by cursor audit are blocked till restart
  • activemq-camel should explicitly Import-Package org.apache.activemq.pool
  • Qpid producer.send with sync_publish=true set against activemq blocks and doesn't return
  • AMQP consumer hangs when receiving large messages
  • " java.lang.ClassCastException: org.apache.activemq.command.ExceptionResponse cannot be cast to org.apache.activemq.command.IntegerResp
  • Ignored InterruptedException in IdGenerator
  • Connections not closing on AMQP connector when client closes its side.
  • AmqpErrorException occurs with multiple concurrent amqp topic consumers
  • ProxyConnector memory usage skyrockets when several ssl handshakes fails
  • Improved:
  • runtime config - add support for spring properties config with properties or bean factory
  • './bin/activemq console' should 'exec' java so that way scripts calling it can get the pid for the broker's java process.
  • Populate a 'Host' header in the WireFormatInfo of the Openwire protocol to let multi-tenant proxies route connections
  • Set headless when running tests.
  • Eclipse build with latest Scala plugins fails
  • Better protect worker thread in TcpTransportServer that handles socket accepts
  • Put back Jolokia management API
  • Reduce the reliance on fsync when writing to disk
  • Test:
  • DynamicallyIncludedDestinationsDuplexNetworkTest.testDynamicallyIncludedDestinationsForDuplex fails on EC2 boxes
  • activemq-unit-tests - A test keep failing testVirtualTopicFailover

New in Apache ActiveMQ 5.8.0 (Jul 25, 2013)

  • Bug:
  • [AMQ-1619] - confluence website misconfigured for custom skin preventing embedded images
  • [AMQ-1719] - Resource adapter stops consuming messages after broker is forcefully stopped/restarted during XA transaction.
  • [AMQ-1870] - JDBC exception when sending and receiving a lot of messages (MySQL 5 in use for persistence)
  • [AMQ-2293] - ActiveMQ Maven plugin fails to spin up broker in multi module project
  • [AMQ-2740] - NullPointerException in Web Console when using an existing browser session with a restarted broker instance
  • [AMQ-2890] - webconsole not working for some 'printable version' links
  • [AMQ-3016] - Race condition in DemandForwardingBridgeSupport can cause remote connection to be leaked.
  • [AMQ-3261] - setup writes incorrect jmx port
  • [AMQ-3331] - When a producer from a network bridge is blocked by producer flow control, all producers from the network bridge get blocked.
  • [AMQ-3539] - Prefetch state can be incorrect when transacted redelivery of duplicates occurs, causing stalled queue
  • [AMQ-3746] - Non Durable Topic subscription with prefetch=0, MessageConsumer.receivenowait() (or MessageConsumer.receive(timeout) hangs indefinitely
  • [AMQ-3851] - Infinite TemqQueue advisory messages
  • [AMQ-3930] - DataFileNotDeletedTest.testForDataFileNotDeletedTransacted() fails intermittently
  • [AMQ-3993] - NetworkBridge sometimes stops trying to reconnect after connection is lost
  • [AMQ-3996] - NIO + SSL: Client certificates are null
  • [AMQ-4022] - Receiving event while disconnecting -> AMQ deadlock -> "Already connected" error
  • [AMQ-4040] - there are two queues with the same name
  • [AMQ-4088] - The perfharness-activemq.sh script has 5.0-SNAPSHOT as version number
  • [AMQ-4090] - Missing svn:ignores
  • [AMQ-4094] - offline durable subs with selectors can lead to page leaks in the index and bloat of db.data in kahadb
  • [AMQ-4095] - Problem with STOMP NIO + SSL
  • [AMQ-4098] - ActiveMQ 5.7 - Misses some binary files in the release kit
  • [AMQ-4099] - [osgi] activemq-blueprint feature failed to install on Karaf 2.3.0
  • [AMQ-4100] - WebSocket connections not cleaned
  • [AMQ-4103] - LeaseDatabaseLocker can not be changed from 5 sec poll
  • [AMQ-4104] - STOMP 1.1 CONNECTED Frame has erroneously encoded headers
  • [AMQ-4106] - STOMP+NIO and Heartbeats gives consistent InactivityIOException
  • [AMQ-4108] - Cannot receive 'ActiveMQ.Advisory.MasterBroker' messages when master dies and slave takes control
  • [AMQ-4110] - Web console can't send messages to the secured broker
  • [AMQ-4111] - Producer hang when tempStorage is full if enable flow control for non-persistent queue
  • [AMQ-4113] - Active mq 5.7.0 doesn't start as a service on windows xp
  • [AMQ-4115] - Make sure there's no XSS in web demos
  • [AMQ-4116] - Memory usage is not cleared from the source queue when a message is moved to another queue over the VMTransport
  • [AMQ-4117] - MQTT Inactivity Monitor doesn't respect client keep alive setting.
  • [AMQ-4118] - Index page overflow (when a value does not fit in a page) can lead to duplicate calls to free
  • [AMQ-4122] - Lease Database Locker failover broken
  • [AMQ-4123] - Improve MQTT Inactivity Monitoring
  • [AMQ-4126] - stomp+nio+ssl + jaasDualAuthenticationPlugin + certificate authentication fails
  • [AMQ-4130] - Duplicated Classes in activemq-spring and activemq-pool artifacts
  • [AMQ-4131] - Duplicated classes in activemq-core and activemq-protobuf artifacts
  • [AMQ-4132] - Openwire+nio+ssl require to specify transport.enabledCipherSuites property
  • [AMQ-4133] - Different behaviour with similar connectors with identical option, URI validation would be nice to have
  • [AMQ-4134] - Add XA support to the LevelDB store.
  • [AMQ-4140] - maven-activemq-plugin fails to resolve path to XBean file in multi-module builds, and does not have a skip flag
  • [AMQ-4142] - SimpleAuthenticationPluginTest hangs intermittently on Hudson
  • [AMQ-4147] - Memory usage incorrectly updated across network of brokers when VMTransport is used.
  • [AMQ-4148] - Static subscriptions from network bridges do not respect TTL (off by one in calculation), resulting in duplicate consumers.
  • [AMQ-4149] - Removal of inactive durable subscribers not working after broker restart
  • [AMQ-4150] - in pure master/slave, when the network is not stable, neither master nor slave can provide service to client
  • [AMQ-4153] - ActiveMQWASInitialContextFactory issue in transform logic
  • [AMQ-4154] - Karaf activemq feature can't be installed due to the unresolved dependencies
  • [AMQ-4156] - Inactivity monitor rejected from thread pool
  • [AMQ-4158] - BTreeIndexTest hangs when run on Windows
  • [AMQ-4159] - Race condition in SimpleDiscoveryAgent creates multiple concurrent threads attempting to connect to the same bridge --- can result in deadlock
  • [AMQ-4160] - DiscoveryNetworkConnector can lose track of active bridges, resulting in permanent bridge failure or continued attempts to re-connect existing bridges
  • [AMQ-4171] - KahaDB / Journal rotateWriteFIle() sometimes too fast?
  • [AMQ-4179] - can't install activemq-extra feature
  • [AMQ-4181] - JMS queue browser returns only page size number of messages
  • [AMQ-4183] - AMQ 5.7 lost long queue names with filteredKahaDB
  • [AMQ-4185] - Unable to access JMSXUserId
  • [AMQ-4186] - web-console xml views have duplicate contenttype headers - jsp errors
  • [AMQ-4187] - [osgi] activemq feature failed to install on Karaf 2.3.0
  • [AMQ-4195] - activemq-admin bstat command predefined query isn't even run
  • [AMQ-4196] - Race condition between removal of subscriptions and removal of destinations in a network of brokers
  • [AMQ-4199] - wrapper.jar missing from 5.7.0 ZIP distro
  • [AMQ-4201] - JMSX* properties not included in the getPropertyNames() enumeration
  • [AMQ-4209] - NetworkConnector and NetworkBridgeConfiguration have same named private variables for excludedDestination
  • [AMQ-4210] - DynamicallyIncludedDestinations is not enforced for the other end of duplex bridge
  • [AMQ-4215] - Simplify PList interface and provide a LevelDB store implementation.
  • [AMQ-4218] - JMS selector statement not displayed correctly in subscribers web view if contains XML-prohibited characters
  • [AMQ-4220] - PageFile is not loaded when recreating queue and perDestination="true"
  • [AMQ-4221] - NPE plist (temp) sparse removal - filependingmessagecursor with selector and expiry
  • [AMQ-4222] - ProducerBrokerExchange holds reference to "region" destination after message has been sent
  • [AMQ-4224] - Setting queue policy queuePrefetch=0 in broker configuration causes messages to stay in pending state in broker - the messages aren't consumed
  • [AMQ-4226] - Broker destination zero prefetch and RAR endpoint listener are incompatible b/c RAR is starved of messages - log an error to highlight
  • [AMQ-4227] - ActiveMQSslConnectionFactory does not allow for regular files to be found unless a valid URL is provided or is located on the classpath
  • [AMQ-4234] - Broker destination policy prefetch value is ignored by stomp consumers
  • [AMQ-4235] - Broker configured prefetch values are lost on failover reconnect
  • [AMQ-4246] - Change Type of offlineDurableSubscriberTimeout and offlineDurableSubscriberTaskSchedule to long
  • [AMQ-4248] - FilePendingMessageCursor can retain memory after flush to disk till next reset via internal iterator
  • [AMQ-4249] - Race condition in PropertiesLoginModule
  • [AMQ-4254] - BrokerXmlConfigStartTest fails intermittently
  • [AMQ-4258] - Endless loop when received incorrect AMQP message
  • [AMQ-4259] - ClassCastException on Durable topic
  • [AMQ-4262] - Pending send transaction can block on store usage and not resume once backlog is cleared
  • [AMQ-4265] - AMQ4220Test is failing
  • [AMQ-4266] - missing proton-api as dependency
  • [AMQ-4274] - Potential deadlock between FailoverTransport and AbstractInactivityMonitor
  • [AMQ-4275] - maven plugin goal "activemq:run" cannot run in latest 5.8 snapshot
  • [AMQ-4276] - Don't restart the network bridge on race condition where respondent sends to a temp dest that has just been deleted
  • [AMQ-4278] - deprecate xmpp transport
  • [AMQ-4281] - ActiveMQConnectionFactoryTest fails intermittently
  • [AMQ-4282] - Deadlock in test BrokerNetworkwithStuckMessageTest
  • [AMQ-4283] - conditionalNetworkBridgeFilterFactory ignores NetworkTTL
  • [AMQ-4285] - NetworkFailoverTest failing
  • [AMQ-4288] - OptimizedAckTest fails intermittently
  • [AMQ-4291] - org.apache.activemq.transport.stomp.StompTest#testReplyToAcrossConnections mostly fails
  • [AMQ-4297] - stomp deadlock on commit
  • [AMQ-4299] - ActiveMQ doesn't start using the service wrapper
  • [AMQ-4345] - NIOSSLConcurrencyTest.testLoad fails on slow boxes
  • [AMQ-4370] - Potential deadlock between FailoverTransport
  • [AMQ-4521] - stomp tcp keepalive not working
  • [AMQ-4533] - Messages stuck in queue with redelivered=true
  • [AMQ-4646] - Backport ability to determine slowness of consumer
  • Improvement:
  • [AMQ-1469] - Change the Default Local Process Name to Something More Descriptive Than "run.jar"
  • [AMQ-1492] - SET AUTOCOMMIT TO OFF is no longer supported Postgre8.1 Error
  • [AMQ-1703] - Create lightweight ActiveMQ client jar
  • [AMQ-2538] - Duplicate queue name in the list
  • [AMQ-3116] - Unicode characters are not shown correctly in message body
  • [AMQ-3173] - Better representation of ActiveMQMessage messages on server page message.jsp.
  • [AMQ-3215] - Drop-down list to move messages from one queue to another is not wide enough to show complete queue names
  • [AMQ-3216] - kahadb should be set optional in manifest file
  • [AMQ-3723] - Namespace handler not compatible with Spring 3.1 bean profiles
  • [AMQ-3757] - Dynamic Failover Sends Clients Resolved Host Names
  • [AMQ-3833] - Only checkpoint data on modification (producerAudit should not be written if unmodified)
  • [AMQ-3864] - Client can't connect to the Network of Brokers without known server's hostname when rebalance
  • [AMQ-3914] - Add support for MS SQL JDBC driver 4.0
  • [AMQ-4055] - Reduce JAR dependency in activemq-core
  • [AMQ-4068] - Job Scheduler Store Growth is Unrestricted
  • [AMQ-4078] - Unable to start ActiveMQ as Windows Service when there is space in the folder path
  • [AMQ-4082] - Refactor network bridge start/stop to reduce async tasks and synchronisation - it is way to complicated atm
  • [AMQ-4089] - The user-guide from the kit should be improved a bit to tell how to stop the broker etc
  • [AMQ-4091] - Allow a memory limit to be configured on a temp topic
  • [AMQ-4124] - Disable sample web application from out of the box broker
  • [AMQ-4125] - deprecate kaha and amq store - kahadb is now well proven
  • [AMQ-4129] - Add support for Stomp v1.2
  • [AMQ-4161] - List of Messages from StatsPlugin is not delimited
  • [AMQ-4165] - Remove pure master/slave functionality
  • [AMQ-4169] - correct maven-X-plugin naming to respect convention
  • [AMQ-4177] - browseMessages() fails when using Jolokia to browse JMX
  • [AMQ-4180] - Use hawtbuf in activemq-client to make message properties and MapMessage body unmarshal more lazy
  • [AMQ-4190] - Figure out what was intended with transactions and producer flow control for topics
  • [AMQ-4198] - Include username in ConnectionInfo for ActiveMQ.Advisory.Connection messages
  • [AMQ-4202] - JMSXUserID missing from ActiveMQConnectionMetaData getter
  • [AMQ-4213] - ActiveMQMessageProducer sends producer registration async which causes it to miss possible exceptions on creation like security exceptions.
  • [AMQ-4225] - PooledConnectionFactory should track Session checkouts and close associated resources
  • [AMQ-4233] - Allow ActiveMQMessageAudit to have cache value for producers set for lower values
  • [AMQ-4237] - JMX ObjectNames do not follow JMX Best practices to use a Hierarchical format
  • [AMQ-4241] - ActiveMQOutputStream shoud reserve the user property only once
  • [AMQ-4250] - activemq-spring - Should not depend on spring-test at compile scope
  • [AMQ-4253] - Upgrade to Spring 3.1.3
  • [AMQ-4279] - deprecate udp transport
  • New Feature:
  • [AMQ-3707] - Dynamic Failover Client Connection Params Broker Side Attribute
  • [AMQ-4024] - Use FQDNs when updating cluster clients
  • [AMQ-4119] - Add memory usage *count* to destination MBean for better detection of memory leaks
  • [AMQ-4121] - Expose Destination.setMemoryUsage so that custom policies can override default MemoryUsage (e.g., to specify message count limits)
  • [AMQ-4144] - When used in a message selector, the JMSDeliveryMode header field should be treated as having the values 'PERSISTENT' and 'NON_PERSISTENT'.
  • [AMQ-4146] - String properties in JMS selector expression should not get auto converted to numbers per spec.
  • [AMQ-4162] - Provide JMX visibility into options applied via destination name query parameters
  • [AMQ-4191] - have a getHappyStatus() method on the BrokerViewMBean so that tools can enquire on the happy status of a broker to see early warning signs of things that could be bad
  • [AMQ-4200] - STOMP 1.1 Over WebSocket
  • [AMQ-4219] - Expose ActiveMQ JMX interface via REST API using Jolokia
  • Task:
  • [AMQ-3944] - Test against the Joram JMS conformance tests.
  • [AMQ-4054] - @deprecate axis support and remove it in AMQ 5.8
  • [AMQ-4087] - Web console - Should use the AMQ logo with the TM
  • [AMQ-4112] - Upgrade to MQTT Client 1.4
  • [AMQ-4163] - Remove old cruft from activemq-camel component such as the kaha journal component
  • [AMQ-4206] - HawtBuf lib in assembly is put into /extra folder when it's not optional
  • [AMQ-4238] - Check AMQ JMX connector code if having same issue as CAMEL-5907
  • [AMQ-4240] - See if ActiveMQ is affected by same issue as CAMEL-5907
  • [AMQ-4252] - activemq-spring - Make OSGi JARs fully optional
  • [AMQ-4256] - Upgrade to OSGi 4.3.0
  • [AMQ-4257] - Upgrade to Aries 1.0
  • [AMQ-4280] - Rename module activemq-core
  • Test:
  • [AMQ-4270] - BrokerNetworkWithStuckMessagesTest hangs occasionally
  • [AMQ-4273] - JobSchedulerTest has 2 test cases that fail intermittently

New in Apache ActiveMQ 5.7.0 (Jul 25, 2013)

  • Sub-task:
  • [AMQ-3945] - QueueBrowser missing messages on first browse.
  • [AMQ-3947] - ActiveMQConnectionFactory doesn't set the nestedMapAndListEnabled property on new Connections
  • [AMQ-3967] - ActiveMQJmsHeaderRouteTest doesn't work with Apache Camel 2.10
  • [AMQ-3968] - ActiveMQJmsHeaderRouteTest doesn't work with Apache Camel 2.10
  • [AMQ-3969] - ActiveMQJmsHeaderRouteTest doesn't work with Apache Camel 2.10
  • [AMQ-3970] - ActiveMQJmsHeaderRouteTest doesn't work with Apache Camel 2.10
  • Bug:
  • [AMQ-2170] - Incoherent documentation / strange property names for advisory messages
  • [AMQ-2453] - start/control-script is not suitable for professional environments
  • [AMQ-2488] - Unable to access Serializable class when receiving ObjectMessage in OSGi environment
  • [AMQ-2521] - Some JMX operations fail with SecurityException with secured broker
  • [AMQ-2656] - ActiveMQInitialConnectionFactory cannot return an XAConnectionFactory
  • [AMQ-2665] - Durable subscription re-activation failed when keepDurableSubsActive=true.
  • [AMQ-3451] - Tomcat 6.0.32 complains that ActiveMQ 5.5 doesn't shutdown a thread
  • [AMQ-3557] - Performance of consumption with JDBC persistance and Microsoft SQL Server
  • [AMQ-3594] - Stuck messages in topic after restart of ActiveMQ
  • [AMQ-3633] - [OSGi] activemq-web-console: exception after restart container
  • [AMQ-3654] - JDBC Master/Slave : Slave cannot acquire lock when the master loose database connection.
  • [AMQ-3664] - Not all messages will be acknowledged when optimizeAcknowledge is true
  • [AMQ-3669] - Pending producer with qMirror, messages are not spooled to disk
  • [AMQ-3727] - activemq-web-console: AjaxServlet not working in OSGi container
  • [AMQ-3785] - ActiveMQSslConnectionFactory does not detect ssl request in failover URIs when creating transports
  • [AMQ-3791] - Flexibility, concurrency, security, and compatibility issues in CachedLDAPAuthorizationMap
  • [AMQ-3797] - org.apache.activemq.util.StringArrayEditor causes classloader leaks
  • [AMQ-3807] - MBeans are not unregistered under WebSphere
  • [AMQ-3827] - The SslContext definition is not used by the https transport protocol.
  • [AMQ-3828] - URISupport incorrectly handles parenthesis
  • [AMQ-3831] - Exit code is not properly returned when using RUN_AS_USER
  • [AMQ-3832] - Upgrade maven-bundle-plugin
  • [AMQ-3836] - STOMP 1.0 protocol (SUBSCRIBE destination) broken on ActiveMQ 5.6.0
  • [AMQ-3837] - BrokerFacade returns more connections than expect when call getConnections by connector name
  • [AMQ-3841] - mKahaDB causes ArrayIndexOutOfBoundsException on restart after deleting existing queues
  • [AMQ-3845] - CachedLDAPAuthorizationMap doesn't handle the ldap connectino dying
  • [AMQ-3846] - The JMX message move, copy and remove operation do not take messages in FIFO order
  • [AMQ-3848] - Messages Are Not Read With Multiple Consumers
  • [AMQ-3849] - Typos in protobuf specs + generated Java code for KahaDB
  • [AMQ-3852] - Stomp transport allows durable topic subscriber to subscribe to a queue
  • [AMQ-3853] - Missing import in activemq-web-console
  • [AMQ-3854] - Referencing old spring xsd in configuration files
  • [AMQ-3855] - MQTT doesn't translate wildcards to ActiveMQ wildcards
  • [AMQ-3856] - MessageServlet assumes TextMessages contain Text
  • [AMQ-3857] - MessageServlet get messages does not return JMS Message Properties
  • [AMQ-3858] - Failure to resolve local jmx url for sunJvm can result in npe
  • [AMQ-3860] - doAddMessageReference missing setting priority into prepared statement therefore using wrong index for message itself
  • [AMQ-3863] - XA session is returned twice to the pool
  • [AMQ-3865] - AjaxTest fails all tests due to line ending differences
  • [AMQ-3867] - Unable to delete messages whose original destination is virtual topic from web console
  • [AMQ-3868] - ActiveMQ 5.6 - RAR deployment is not working on JBoss6
  • [AMQ-3870] - ArrayIndexOutOfBoundsException when using Multi kahaDB (mKahaDB) adapter, per-destination adapters and Topics
  • [AMQ-3871] - Problem in OrderPendingList can lead to message not being deliver after durable sub reconnect.
  • [AMQ-3872] - Implement "exactly once" delivery with JDBC and XA in the event of a failure post prepare
  • [AMQ-3873] - Occasional deadlock during startup
  • [AMQ-3879] - Temporary queues may be deleted by the wrong connection
  • [AMQ-3881] - Handy diagnostic script for troubleshooting ActiveMQ problems
  • [AMQ-3882] - Broker should not send advisories for slow consumers or fast producers if the destination in question is an advisory destination already.
  • [AMQ-3885] - ActiveMQ java client doesn't scale to thousands of queues
  • [AMQ-3887] - Occasional Null Pointer Exception during NetworkConnector connection
  • [AMQ-3889] - Body Preview of BytesMessages change when browsed multiple times from QueueViewMbean
  • [AMQ-3891] - Durable subscribers receiving duplicate messages
  • [AMQ-3895] - Broker sends a STOMP RECEIPT frame although the subscription fails
  • [AMQ-3896] - AMQ3622Test throws NumberFormatException on ec2/ubuntu 10.04
  • [AMQ-3897] - Stomp 1.1 keep alive does not work with stomp+nio
  • [AMQ-3903] - Failed to fire fast producer advisory, reason: java.lang.NullPointerException
  • [AMQ-3905] - Karaf: activemq:create-broker results in only locally visible broker
  • [AMQ-3908] - StompSslAuthTest.testSubscribeWithReceiptNotAuthorized() fails
  • [AMQ-3909] - Messages sometimes not received by active topic subscriptions
  • [AMQ-3912] - Durable subs store messages in error with broker attribute persistent="false"
  • [AMQ-3915] - JMX connector does not bind to a specific host when a connectHost is specified on the managementContext
  • [AMQ-3919] - getDestinationMap does not return temp destinations
  • [AMQ-3920] - Performance issue with delay policy in DestinationBridge.onMessage
  • [AMQ-3921] - Duplicated durable subscriptions after broker retart with option keepDurableSubsActive=true
  • [AMQ-3923] - Webconsole should import javax.servlet.* too
  • [AMQ-3925] - Advisory messages/topics not generated for ActiveMQ.Advisory.FULL or ActiveMQ.Advisory.FastProducer.Queue
  • [AMQ-3927] - can't connect to stomp protocol 1.1 using telnet
  • [AMQ-3929] - STOMP multiple header handling incorrect per the 1.1 spec
  • [AMQ-3931] - Memory problems with large transactions
  • [AMQ-3932] - receiveNoWait hangs when broker is down, using failover and prefetch=0
  • [AMQ-3934] - QueueViewMBean.getMessage throws NullPointerException when message not found
  • [AMQ-3935] - JConsole browse() function does not work if useCache=false
  • [AMQ-3936] - activemq status return codes should be LSB compliant
  • [AMQ-3939] - FailoverTransport never closes backup connections
  • [AMQ-3943] - Connect to ActiveMQ server's jmx feature,but failed.
  • [AMQ-3951] - LDAP Connection Timeouts in CachedLDAPAuthorizationMap
  • [AMQ-3953] - org.apache.activemq.util.URISupport.isCompositeURI doesn't work properly.
  • [AMQ-3954] - Intended delivery mode for JMSUsecaseTest is not tested
  • [AMQ-3955] - WebSocket Transport - Race condition starting transport
  • [AMQ-3956] - KahaDB pagefile (db.data) steady growth - BTreeIndex page leak
  • [AMQ-3958] - META-INF/spring.schemas does not contain a reference to 5.6.0 schema
  • [AMQ-3961] - Durable subscriber only receives part of the persisted messages on re-connect
  • [AMQ-3962] - Memory leak bacause of InactivityMonitor thread
  • [AMQ-3965] - Expired msgs not getting acked to broker causing consumer to fill up its prefetch and not getting more msgs.
  • [AMQ-3973] - data.db size is not included in calculation to monitor systemUsage settings
  • [AMQ-3976] - ActiveMQMessageProducer::send uses == instead of equals to compare destinations
  • [AMQ-3979] - AjaxServlet preventing Tomcat Container from shutting down.
  • [AMQ-3981] - ActiveMQSslConnectionFactory.java now has apache commons dependency
  • [AMQ-3982] - Overlapping PList iterators can read wrong data or throw exceptions about chunk streams not existing.
  • [AMQ-3985] - ActiveMQConnection temp advisory consumer should use asyncDispatch - can cause deadlock with slow consumers
  • [AMQ-3987] - For JMSUsecaseTest, incompatible types found : javax.jms.Message required: org.apache.activemq.Message
  • [AMQ-3988] - PooledSession throw Exception at closing
  • [AMQ-3989] - ActiveMQSslConnectionFactory.setKeyAndTrustManagers does not work with failover enabled using 5.7 snapshot Jars
  • [AMQ-3992] - Zero Prefetch consumers increment the Enqueue Counter when the pull times out
  • [AMQ-3994] - DefaultDatabaseLocker will leak pooled connections on link failure
  • [AMQ-3995] - PListTest.testSerialAddIterate runs for over 30 minutes on Hudson nodes
  • [AMQ-3997] - Memory leak in activemq-pool
  • [AMQ-3998] - Incorrect reporting of pendingQueueSize of durable subs after reconnect with unacked
  • [AMQ-3999] - Unsubscribing durable subs can be blocked on calls to determine store size, contending with active subs
  • [AMQ-4001] - activemq karaf feature uses different commons-lang than pom
  • [AMQ-4002] - Instance of BlobTransferPolicy and its URL are being shared among multiple messages
  • [AMQ-4007] - BrokerService TempUsage and StoreUsage Default Values Are Incorrect
  • [AMQ-4017] - Demand Forwarding Bridge uses value of asyncDispatch for advisory consumers
  • [AMQ-4030] - Tomcat7 with ActiveMQ-5.6 or ActiveMQ-5.7 starts with error
  • [AMQ-4031] - BrokerFactoryBean logs error when starting a non persistent broker
  • [AMQ-4033] - AMQ Broker - Uses custom RMIServerSocketFactory class which cannot be unloaded due socket reuse
  • [AMQ-4035] - Null pointer in class KahaDBStore programmed
  • [AMQ-4042] - Rest MessageServlet on osgi failes to start
  • [AMQ-4043] - Web demo - Receive a message page renders an error page
  • [AMQ-4044] - Shutting down AcitveMQ broker started in foreground logs 2 times
  • [AMQ-4047] - activemq-optional - Should include the JARs it needs
  • [AMQ-4052] - When consumers was killed and restarted frequently, some messages could not be consumed by consumer but they were still in pending messages.
  • [AMQ-4058] - http transport should remove options in uri
  • [AMQ-4062] - durableTopicPrefetch attribute in policyEntry in activemq.xml dont take effect
  • [AMQ-4070] - catstomp.rb does not work anymore
  • [AMQ-4076] - sizePrefixDisabled and/or maxFrameSize change in AcriveMq 5.6 broke FilePendingMessageCursor for big messages
  • [AMQ-4081] - favicon should be handled as binary file in assembly
  • [AMQ-4083] - Consumers in Client Ack sessions can fail to ack expired messages in some cases
  • [AMQ-4084] - Linux/Unix Files Have Incorrect EOL When Packaged
  • [AMQ-4090] - Missing svn:ignores
  • Improvement:
  • [AMQ-3060] - java.lang.ClassCastException: org.apache.activemq.broker.region.QueueSubscription cannot be cast to org.apache.activemq.broker.region.DurableTopicSubscription
  • [AMQ-3224] - Redelivery per destination
  • [AMQ-3444] - Fail Fast or Warn on using fileCursors/fileQueueCursors when
  • [AMQ-3534] - Fixes to poms to allow eclipse indigo and m2eclipse to not show errors.
  • [AMQ-3554] - activemq:create command should use name as argument in place of option
  • [AMQ-3696] - Slave broker cannot be stopped in a JDBC Master/Slave configuration within OSGi
  • [AMQ-3770] - Generalize LDAP group processing / LDAP group expansion
  • [AMQ-3813] - limit the number of producers and consumers created by a Connection
  • [AMQ-3815] - Hybrid Master Slave Architecture
  • [AMQ-3822] - The current sslContext element does not provide the ability to define the keystore key password key.
  • [AMQ-3847] - Optional import for org.apache.activemq.pool in activemq-camel should be required
  • [AMQ-3859] - To tight version range in activemq features file
  • [AMQ-3861] - Offer a way to not set a transaction manager in activemq-camel
  • [AMQ-3877] - Add ability to set a timeout for the calls made to Broker MBeans
  • [AMQ-3878] - Reset stats automatically without dependancy on JMX / Java APIs
  • [AMQ-3890] - Turn dependency on fusemq-leveldb optional
  • [AMQ-3893] - Adjust topic policy entry in default configuration
  • [AMQ-3902] - Documentation for JMS Bridge With Oracle AQ
  • [AMQ-3913] - Stomp Spec allows for stomp headers to have spaces in key or value we currently trim.
  • [AMQ-3918] - Expose transport connector URIs in uniform fashion
  • [AMQ-3940] - REST API - support application/json response type
  • [AMQ-3950] - Blueprint version should be [0.3,2)
  • [AMQ-3960] - Update 5.7 to use Apache Camel 2.10.x
  • [AMQ-3972] - Add an 'isDisposed' check before calling 'propagateFailureToExceptionListener' in FailoverTransport
  • [AMQ-3980] - Websocket transport: support increasing the max size of websocket messages
  • [AMQ-3983] - Fix osgi dependency
  • [AMQ-3986] - Allow optimizeDurableTopicPrefetch to be set using resource adapter properties
  • [AMQ-3991] - Output version number in started log line to be consistent
  • [AMQ-4003] - Add option to PooledConnectionFactory to control if connection should be created on startup or not
  • [AMQ-4004] - activemq-pool - Rename maximumActive option maximumActiveSessionPerConnection
  • [AMQ-4008] - Tomcat WARN on shutdown about ThreadLocal not cleared from log4j
  • [AMQ-4010] - Use pre compiled patterns for JMX ObjectName encoder
  • [AMQ-4011] - Refactor IntrospectionSupport to avoid using java bean property editors
  • [AMQ-4012] - Use english locale for introspection support when discovering setter/getter method names
  • [AMQ-4015] - Add uptime to broker mbean and when stopping broker to report its uptime
  • [AMQ-4016] - org.apache.activemq.ActiveMQConnectionFactory - Seems like static thread pool is not used
  • [AMQ-4019] - Make better use of commons-pool in activemq-pool
  • [AMQ-4026] - Refactor logic to shutdown thread pools using a single API to ensure better shutdown and offer logging et all
  • [AMQ-4027] - Add support for java 7 in AbstractJmxCommand
  • [AMQ-4028] - Add support for testing secured web sockets
  • [AMQ-4029] - Unregistering mbean should handle null mbean names
  • [AMQ-4049] - Polish the AMQ start|stop logging
  • [AMQ-4057] - activemq-option - Upgrade to http client 4.2
  • [AMQ-4060] - activemq-optional - Upgrade Spring OXM to Spring 3 version
  • [AMQ-4063] - Trim RAR to not included Derby JAR
  • [AMQ-4066] - Cleanup of old deprecated methods and classes from the code base.
  • [AMQ-4067] - Prefix Thread names with ActiveMQ
  • [AMQ-4069] - Upgrade Maven Plugins
  • [AMQ-4075] - More transparent KahaDB file lock switch
  • New Feature:
  • [AMQ-2106] - Allow broker to evenly distribute message groups among consumers
  • [AMQ-3298] - Cannot create bridge to WebSphere queue using default messaging provider
  • [AMQ-3787] - useCompression on server side specially on network of brokers
  • [AMQ-3880] - WSS transport
  • [AMQ-3894] - Add support for Broker based redelivery
  • [AMQ-3917] - ActiveMQ should support multiple durable subscriptions per Stomp client
  • [AMQ-3924] - Allow REST API to connect to the secured broker
  • [AMQ-4005] - Implement pluggable broker lockers
  • [AMQ-4065] - Add optional destination suffix for the IndividualDeadLetterStrategy
  • Task:
  • [AMQ-3784] - Download page lists lots of releases; they are not in order and most of the pages point to the wrong location
  • [AMQ-4006] - activemq-pool - Upgrade to commons-pool 1.6.0
  • [AMQ-4013] - Upgrade to xbean 3.11
  • [AMQ-4038] - Favor using JARs from Maven central
  • [AMQ-4039] - Upgrade 3rd party dependency JARs and align with SMX/Camel
  • [AMQ-4041] - Upgrade ActiveMQ karaf feature
  • [AMQ-4045] - Unit test shows NPE in BrokerService
  • [AMQ-4053] - Cleanup duplicate JARs in ActiveMQ distro
  • [AMQ-4056] - Remove activemq-jmdns module
  • Test:
  • [AMQ-3900] - Thread.sleep call in TopicProducerFlowControlTest sleeps too long on Ubuntu, causing test timeout

New in Apache ActiveMQ 5.6.0 (Jul 25, 2013)

  • Sub-task:
  • [AMQ-3706] - Dynamic Failover Randomize is Not Evenly Balanced
  • Bug:
  • [AMQ-796] - Client may shtudown when failover connection is reconnecting. We need to maintain at least 1 non-daemon thread alive.
  • [AMQ-819] - There should be no active/inactive disction in JMX Type=Subscription MBean
  • [AMQ-1132] - activeio test package inclusion and logging properties
  • [AMQ-1203] - Killing STOMP client stalls the Q forever until a new message is written to that Q
  • [AMQ-1529] - The blob of a blob-message will never be deleted
  • [AMQ-1706] - out of date javadoc for org.apache.activemq.ActiveMQConnectionFactory.setDispatchAsync @param, default value is true on trunk
  • [AMQ-1899] - Sending without entering a queue name creates an empty queue with a message into it
  • [AMQ-1942] - Numeric selectors do not work in STOMP
  • [AMQ-1958] - JDBC master/slave deadlock when connection is lost
  • [AMQ-1990] - Failing network connectors randomly log SEVERE message : Could not accept connection : java.lang.Object cannot be cast to org.apache.activemq.command.Command
  • [AMQ-2060] - Not able to receive messages using 'http' (transportConnector) connection
  • [AMQ-2076] - Intermittent test failure - DataFileNotDeletedTest
  • [AMQ-2093] - Message Selector Not working in High Load.
  • [AMQ-2126] - Expired messages not being removed from the queue
  • [AMQ-2202] - BrokerView Returns Invalid ObjectName Array Size For InactiveDurableTopicSubscribers
  • [AMQ-2211] - activemq-core activeio-core test-jar
  • [AMQ-2248] - PrefetchSubscription NullPointerException
  • [AMQ-2294] - MessageProducer hangs when using many concurrent sessions
  • [AMQ-2301] - Connection view in ActiveMQ web console lists empty lines.
  • [AMQ-2329] - Queue.send NPE in broker => inoperative broker
  • [AMQ-2349] - Temporary destinations created with PooledConnectionFactory never get deleted
  • [AMQ-2353] - Files was unexpected at this time error - while starting activemq service on windows 2003 64 bits machine
  • [AMQ-2361] - No Of connections Increases at Server end
  • [AMQ-2362] - ActiveMQ5.2 - Some listeners stopped getting messages. Even after restart of the broker/client the messages were not getting picked. Then we stopped ActiveMQ 5.2 and started Active mq 4.1 (we migrated some one week back) and then client and it worked
  • [AMQ-2363] - Client using 41 API and Server is running on 5.2
  • [AMQ-2372] - Number of pending messages are greater than 0 but no actual messages on queues
  • [AMQ-2373] - Expired Messages appear through policy entry on the DLQ and are also processed from the main Queue
  • [AMQ-2414] - JDBC datastore locking does not work when using MYSQL cluster
  • [AMQ-2430] - embedded RESTful fileserver do not close files when PUT method is called
  • [AMQ-2464] - AbstractJmxCommand depends on sun.management.ConnectorAddressLink
  • [AMQ-2498] - Broker goes down when database is restarted or goes down
  • [AMQ-2502] - activemq-camel is missing an optional Import-Package for org.apache.activemq.pool
  • [AMQ-2517] - Client stops receiving messages from topic after about 30 minutes of inactivity
  • [AMQ-2521] - Some JMX operations fail with SecurityException with secured broker
  • [AMQ-2524] - Messages are lost and no exception raised when queue is deleted and created by another process.
  • [AMQ-2526] - Questionable processing of interruptions in TcpTransport::doStop
  • [AMQ-2528] - org.apache.activemq.broker.region.Queue#removeMatchingMessages(String selector) does not allow empty string as a selector, but empty string is a valid JMS message selector.
  • [AMQ-2552] - Automatic message expiration may not occur on a queue with no (or slow) consumers.
  • [AMQ-2553] - Browsing DLQ over transacted session
  • [AMQ-2558] - Oracle JDBC Driver 10g Release 2 (10.2.0.4) not recognized
  • [AMQ-2615] - activemq-admin stop does not work when waiting for exclusive locks
  • [AMQ-2639] - Annotation error with IBM 1.5 JVM
  • [AMQ-2641] - Timestamp Order
  • [AMQ-2643] - Closing a PooledConnection does not seem to return associated sessions to the SessionPool
  • [AMQ-2648] - Interrupting Consumer.close() thread puts queue into unusable state
  • [AMQ-2649] - jdbcPersistenceAdapter adapterClass attribute does not exist
  • [AMQ-2652] - ActiveMQ non-conformance to JMS Spec causing deadlock when using 3rd-party Resource Adapter
  • [AMQ-2655] - connection stats appear broken
  • [AMQ-2657] - temp-queue - no producer, no consumer -> messagecount
  • [AMQ-2666] - JMX does not indicate durable subscription activity.
  • [AMQ-2679] - "VMTransport" NullPointerException from ActiveMQSessionExecutor.wakeup
  • [AMQ-2690] - kahaDB: maxCheckpointMessageAddSize not accepted
  • [AMQ-2703] - Mix of Persistent and Non-Persistent producers on the same queue breaks producer flow control
  • [AMQ-2717] - Crashing and restarting the broker causes message redelivery even if the XA transaction was already prepared (but not commited)
  • [AMQ-2721] - Broker hangs reading KahaDB data store
  • [AMQ-2743] - Pure master/slave configuration will not failover to slave when master fails
  • [AMQ-2759] - Nullpointer-Exception in Queue.send
  • [AMQ-2773] - javax.jms.TopicPublisher is not announced via Advisory Topic
  • [AMQ-2778] - Memory leak with ManagedRegionBroker
  • [AMQ-2780] - ActiveMQ not preserving Message Order
  • [AMQ-2801] - Durable subscriber on startup ignores Selectors when calculating pending queue size
  • [AMQ-2804] - Database lock driver override not found for : [oracle_jdbc_driver]. Will use default implementation.
  • [AMQ-2846] - Apache Camel Activemq component does not allow use of "consumer.retroactive=true"
  • [AMQ-2868] - NegativeQueueTest and JDBC variant - intermittent failure - missing message when cache exhausted
  • [AMQ-2908] - Slow consumer stops receiving messages because PrefetchSubscription.dispatched is filled with expired messages.
  • [AMQ-2920] - new ActiveMQ 5.4.0 sysv start script redirects process stdout and stderr to /dev/null
  • [AMQ-2923] - Clients are sent messages out of producer-order
  • [AMQ-2939] - Disable Spring 3 schema validation
  • [AMQ-2971] - DestinationStatistics.getMessages() returns 0 after reset with messages still in queue
  • [AMQ-2974] - Set ClientID - InvalidClientIDException with stomp
  • [AMQ-3004] - Build-up of unwanted messages
  • [AMQ-3008] - Queue destination bridge does not stay up
  • [AMQ-3012] - HttpTunnelServlet incorrectly swallows exceptions during transport creation.
  • [AMQ-3014] - DemandForwardingBridgeSupport can send BrokerInfo to remote transport before local broker ID is known.
  • [AMQ-3023] - DestinationView.browseMessages(String) must not call OpenTypeSupport.convert()
  • [AMQ-3031] - Time Synchronization Solution
  • [AMQ-3070] - New clients unable to connect to broker while SubscriptionRecoveryPolicy is running
  • [AMQ-3104] - kahaDB 3 fails to start after server VM reset
  • [AMQ-3131] - Failed to reset batching ... java.lang.IllegalStateException: PageFile is not loaded
  • [AMQ-3154] - unable to implement custom broker-to-broker authorization
  • [AMQ-3157] - Garbage collecting inactive destinations does not work with queue mirroring
  • [AMQ-3163] - bin/activemq error on MacOS (and maybe Cygwin)
  • [AMQ-3168] - Broker XSD: boolean attributes should permit value injection via Srping's PropertyPlaceholderConfigurer
  • [AMQ-3210] - OutOfMemory error on ActiveMQ startup
  • [AMQ-3213] - failover doesn't reconnect after broker restart
  • [AMQ-3214] - "InactivityMonitor Async Task" threads leaking
  • [AMQ-3251] - javax.jms.TransactionInProgressException: Cannot rollback() inside an XASession
  • [AMQ-3262] - Browser closed while iterating changes message delivery order
  • [AMQ-3269] - ACTIVEMQ_OPTS_MEMORY is ignored
  • [AMQ-3272] - Handle RejectedExecutionException
  • [AMQ-3273] - Slave broker acquires lock file when Master is still alive (shared file system master/slave setup)
  • [AMQ-3274] - duplicate messages on Temporary Topics in network of brokers
  • [AMQ-3275] - Make UDP protocol work
  • [AMQ-3276] - ConcurrentModificationException in embedded 5.5.0 broker
  • [AMQ-3277] - Deadlock with static:(failover:(...)) configuration
  • [AMQ-3279] - KahaDB does not clean old files in combination with network connectors
  • [AMQ-3282] - The wrapper.conf shipped in the linux-x86-32 and linux-x86-64 incorrectly specifies libwrapper.so
  • [AMQ-3283] - Support for transactions broken in maven-activemq-perf-plugin
  • [AMQ-3284] - WebSockets and truncated body
  • [AMQ-3288] - JDBC persistence adapter, intermittent performance degradation when a durable subscriber of priority messages falls behind
  • [AMQ-3289] - ActiveMQ has problems storing >4K messages in Oracle
  • [AMQ-3292] - KahaDb Transaction iterator remove doesn't throw Runtime Exception
  • [AMQ-3293] - ActiveMQ broker hangs after sending many large messages with a TTL, and no DLQ
  • [AMQ-3294] - ActiveMQ failover Denial of Service
  • [AMQ-3296] - Remove (old version) slf4j-api lib from amq releases
  • [AMQ-3301] - LockFile in-jvm check is not thread-safe
  • [AMQ-3306] - Cron parser doesn't understand '?'
  • [AMQ-3307] - Message scheduled via cron to a broker with persistence enabled, is only delivered once
  • [AMQ-3309] - 5.5.0 - kahadb indexing to be reviewed
  • [AMQ-3310] - IOException PListStore "Could not locate data file" from FilePendingMessageCursor
  • [AMQ-3312] - Queue's moveMatchingMessagesTo method is extremely slow to the point of being unusable as Queue size increases
  • [AMQ-3314] - FilePendingMessageCursor isFull reports full in error when temp store is full, even if not needing the temp store
  • [AMQ-3316] - Memory leak in ConnectionStateTracker with MessagePull objects
  • [AMQ-3319] - A possible browsing concurrency issue in org.apache.activemq.broker.region.Queue
  • [AMQ-3325] - PList temp store, chunk stream does not exist when broker under stress
  • [AMQ-3331] - When a producer from a network bridge is blocked by producer flow control, all producers from the network bridge get blocked.
  • [AMQ-3342] - Shutdown of broker waiting for shared fileystem lock blocks
  • [AMQ-3352] - failover ConnectionStateTracker can lead to OOM with TextMessages
  • [AMQ-3353] - Durable subscribers on durable topics don't receive messages after network disconnect
  • [AMQ-3357] - vmQueueCursor or fileQueueCursor with expired messages in the store can lead to startup hang with kahaDB
  • [AMQ-3374] - Long KahaDB transactions could lead to OutOfMemory
  • [AMQ-3375] - stomp consumer might not receive all msgs of a virtual topic queue with memory limits
  • [AMQ-3380] - Exclusive consumers do not rollback session when switched after master slave failover
  • [AMQ-3381] - Connections web console page shows two rows per connection (one empty)
  • [AMQ-3382] - staticallyIncludedDestinations should always be forwarded
  • [AMQ-3393] - Number of established STOMP connections constantly increasing
  • [AMQ-3401] - ActiveMQ cannot determine between Queue and Topic for Weblogic destination
  • [AMQ-3404] - Purge command does not accept message selectors
  • [AMQ-3414] - InactiviryMonitor Async Task thread overflow when date changes
  • [AMQ-3422] - BitArray serialization
  • [AMQ-3426] - AbstractRegion.java has incorrect null check in contructor
  • [AMQ-3427] - Activemq-trunk does not compile with JDK7
  • [AMQ-3430] - activemq-web: SessionPool.returnSession() should discard sessions that are closed.
  • [AMQ-3434] - Contention in PLIist creation results in NPE on load - FilePendingMessageCursor
  • [AMQ-3435] - Connection is taking a long time to close warning and hung close thread
  • [AMQ-3443] - checkpoint contention with large transaction write using temp file
  • [AMQ-3454] - Contention on a mutex during a stress when using SimpleAuthenticationPlugin
  • [AMQ-3455] - Broker may deadlock when creating queues under load with wildcard consumers
  • [AMQ-3457] - temp destinations should only be deleted once all users of a pooled connection call close
  • [AMQ-3459] - Inactive durable subscribers view doesn't show selector
  • [AMQ-3463] - Sync pom and osgi metadata
  • [AMQ-3465] - TransactionContext produces errors in concurrent environment
  • [AMQ-3466] - IndexOutOfBounds in kahadb with large number of subscriptions and pending messages
  • [AMQ-3473] - Messages (possibly) stuck and pending messages count showing high number of pending message which do not get sent to a consumer.
  • [AMQ-3481] - Possible Stomp deadlock
  • [AMQ-3488] - Temporary destinations' DestinationInfo commands over VM transport prevent connection closure
  • [AMQ-3490] - NPEs during message processing, using FileCursor
  • [AMQ-3493] - Incorrect JMX properties after consuming msgs using stomp (with TX and client ack)
  • [AMQ-3497] - STOMP subscription receipt can be out of order with message dispatch, resulting in consumer/client error
  • [AMQ-3501] - Stomp v1.1 support, headers, eg: message-id, are not properly escaped
  • [AMQ-3504] - NullPointerException on websocket connection
  • [AMQ-3506] - Access to ConnectionPool.createSession needs to be synchronized
  • [AMQ-3507] - Large number of expiring messages causing QueueSize to grow.
  • [AMQ-3513] - initialReconnectDelay is ignored for Failover transport
  • [AMQ-3514] - MessageListenerServlet does not clear the timer on destroy
  • [AMQ-3515] - MultiKahaDBPersistenceAdapter can not set directory
  • [AMQ-3516] - Failover Transport MessageAck commands aren't filtered in oneway
  • [AMQ-3517] - Failover Transport will never call transportResumed when it reconnects to a hot backup transport.
  • [AMQ-3518] - MessageServletSupport request body does not check the content-type in an intelligent way
  • [AMQ-3523] - NetworkConnector MBean unregistration can fail with a transport disconnect - leaving dangling mbean
  • [AMQ-3524] - NullPointerException in TraceBrokerPath plugin.
  • [AMQ-3525] - Messages seem to be getting stuck on queues
  • [AMQ-3526] - JDBC persistence adapter, destination mbeans not visible on restart till producers or consumers reattach
  • [AMQ-3527] - ./activemq script cannot be started on Solaris OS 10
  • [AMQ-3529] - Calling Thread.interrupt while in MessageConsumer#receive(timeout) generates java.io.InterruptedIOException and leaks Connection
  • [AMQ-3532] - expiry of offline durable subscription on activation can lead do duplicate expiry processing and negative pending cursor size
  • [AMQ-3535] - ActiveMQMessageConsumer auto ack of duplicates always sends a standard ack
  • [AMQ-3536] - Virtual Topic Subscriber and Individual Dead Letter Queue Handling
  • [AMQ-3537] - ClassLoadingAwareObjectInputStream cannot handle deserializing proxies with mixed JDK & non-JDK interfaces
  • [AMQ-3542] - Using failover: with static discovery in a network connector to choose from a master/slave tuple leads to hangs and invalid states
  • [AMQ-3543] - STOMP connector: unexpected reply-to value for remote temporary topic
  • [AMQ-3547] - Calling Connection.close() on interrupted thread generates InterruptedIOException and leaks Connection
  • [AMQ-3552] - activemq:list doesn't use the correct Karaf JMX URL by default
  • [AMQ-3556] - HttpTransport not playing nice with Compression and sending TextMessage
  • [AMQ-3559] - KahaDB NPE when loading data from previous versions
  • [AMQ-3560] - Destinations do not implement javax.resource.Referenceable and will not be registerable in JNDI by some compliant JCA containers.
  • [AMQ-3561] - activemq-web-console feature create the web-console broker in a bad folder
  • [AMQ-3562] - HttpTransport can generate an IllegalStateException when KeepAliveResponseRequired = true
  • [AMQ-3567] - The InactivityMonitor onException call interrupts itself when the readCheckTime was exceeded.
  • [AMQ-3568] - Consumer auto acking of duplicate message dispatch can lead to Unmatched acknowledge: and redelivery
  • [AMQ-3575] - Failover transport race condition causes intermittent incomplete bridge connections
  • [AMQ-3576] - ProducerBrokerExchange last producer sequenceId initialization needs runtime updates to deal with possible duplicate resends
  • [AMQ-3577] - The Connection is not cleanup properly whenever the close method is called within a thread that was interrupted.
  • [AMQ-3578] - Java Wrapper Service does not Start on Windows 7 Enterprise SP1
  • [AMQ-3581] - Web Console: escape link urls
  • [AMQ-3586] - spaces in queue name
  • [AMQ-3588] - PooledSession - Can cause memory leak in case many consumers is created by the session
  • [AMQ-3590] - activemq-web REST servlet support for JMSType is broken via typo
  • [AMQ-3596] - FilePendingMessageCursor memory list does not respect priority for non persistent messages
  • [AMQ-3599] - JaasDualAuthenticationPlugin, java.net.BindException: Address already in use on shutdown with pending connectons
  • [AMQ-3600] - Failover reconnect bypasses DestinationPathSeparatorBroker generating invalid destinations
  • [AMQ-3601] - when using http transport xstream cannot construct org.apache.activemq.util.ByteSequence as it does not have a no-args constructor
  • [AMQ-3605] - NullPointerException in TransportConnection
  • [AMQ-3606] - Features descriptor should define the namespace
  • [AMQ-3607] - Setting OptimiseAcknowledge on a queue with a prefetch limit causes normal/fast consumers to miss messages when a slow consumer is blocking
  • [AMQ-3614] - Unable to generate unique id when range of ports are blocked - org.apache.activemq.util.IdGenerator
  • [AMQ-3618] - when using openwire with cacheEnabled=false memory is wasted on unmarshallCache[] and marshallCache[]
  • [AMQ-3622] - NPE in LastImageSubscriptionRecoveryPolicy
  • [AMQ-3625] - NullPointer Exceptions when networked broker sends certificate with an invalid user name
  • [AMQ-3627] - IndexOutOfBoundsException in org.apache.activemq.store.kahadb.MessageDatabase.getFirstInProgressTxLocation()
  • [AMQ-3628] - AMQ3567Test doesn't clean up appender after AMQ-3623 update
  • [AMQ-3630] - NetworkBridgeFilterFactory should be assigned to Queue not NetworkBridge
  • [AMQ-3635] - JmsTopicConnector checks for presence of localClientId then uses outboundClientId
  • [AMQ-3637] - NullPointerException while loading node from kahadb during vmcursor replay
  • [AMQ-3649] - NPE when KahaDB fails to store to Journal with EOFException
  • [AMQ-3651] - If the broker binds RMI registry port when it starts up, the broker should release RMI registry port when it shuts down
  • [AMQ-3653] - content-length header should be considered only for SEND frames
  • [AMQ-3655] - No information of destinations is present on web console or jconsole even my activemq_msgs, have lots of destinations when broker starts up
  • [AMQ-3665] - Velocity's IntroSpectionCache causes OutOfMemoryError on large AMQ stores when running activem-admin journal-audit
  • [AMQ-3670] - Fix NACK support for Stomp
  • [AMQ-3672] - NPE exception when querying a starting broker use JMX program
  • [AMQ-3673] - Unexpected behavior in FailoverTransport when hosts are unknown
  • [AMQ-3674] - TopicRegion removes durableScriber from durableSubscriptions when it is active; but leaves subscription on Topic
  • [AMQ-3675] - Removing a DurableTopicSubscription leaves subscription in active subscriptions map
  • [AMQ-3678] - Active Durable Topic Consumer is not re-assigned to Topic after it is deleted and recreated
  • [AMQ-3680] - Cleanup of temporary destinations by PooledConnection and ConnectionPool either leaks temp dests or deletes too many
  • [AMQ-3681] - DatabaseLocker should first cancel locking SQL statement before closing the SQL connection
  • [AMQ-3684] - Potential deadlock in vm transport setListener when sender is blocked pending space
  • [AMQ-3685] - Failover cluster update broken when url contains server side options
  • [AMQ-3694] - Blocked/Slow advisory consumers in duplex network connector, eventually breaks request/reply with temps
  • [AMQ-3695] - Failover using a JDBC Message Store and Virtual Topic can result in a lost message if queue is empty
  • [AMQ-3700] - java.util.ConcurrentModificationException in org.apache.activemq.broker.region.Queue.iterate()
  • [AMQ-3709] - Patch to fix invalid XHTML in web-console's 404 and 500 pages
  • [AMQ-3715] - activemq-all.jar is missing the slf4j-log4j12 dependency
  • [AMQ-3716] - NetworkBridge with conduitSubscriptions=true will leak consumer info in org.apache.activemq.network.DemandForwardingBridgeSupport#subscriptionMapByRemoteId map
  • [AMQ-3719] - Tracked command IOException causes FailoverTransport to hang until failure occurs for untracked command
  • [AMQ-3722] - "activemq-admin browse" help command prints incorrect argument name for password in sample usage
  • [AMQ-3724] - Dynamic Failover Blocks NetworkConnector & Queue MBean Creation
  • [AMQ-3726] - JavaDoc on main banner points ActiveMQ 5.5.0 JavaDocs and not 5.5.1
  • [AMQ-3729] - Stomp wireformat and codec block on telnet CRLF CRLF header separator
  • [AMQ-3731] - Suspicious NPE in log when network bridge cannot be established and loggingBrokerPlugin configured
  • [AMQ-3732] - Different methods synchronizing on different mutexes when changing the same field
  • [AMQ-3733] - Topic subscriber is assumed to be slow consumer when prefetch is set to one.
  • [AMQ-3735] - Java service wrapper ${activemq.conf} not found
  • [AMQ-3737] - Possible leak in ManangedRegionBroker unregisterDestination
  • [AMQ-3742] - STOMP subscriber does not receive TextMessage with null body sent from JMS
  • [AMQ-3743] - activemq-web-console WAR with SNAPSHOT dependencies breaks osgi Bundle-ClassPath in manifest
  • [AMQ-3744] - FailoverTransport connects to inactive slave Broker
  • [AMQ-3745] - Exception while killing the broker
  • [AMQ-3748] - ActiveMQEndpointWorker$1: Run method is synchronized
  • [AMQ-3749] - Composite destinations break simple authorisation through role aggregation
  • [AMQ-3752] - Repeated call to PooledConnection.setClientID() with the same clientId should not raise a IllegalStateException("Setting clientID on a used Connection is not allowed")
  • [AMQ-3753] - Exception on stopping the broker - Timer already cancelled
  • [AMQ-3754] - intermittent failure of org.apache.activemq.transport.vm.VmTransportNetworkBrokerTest
  • [AMQ-3756] - Source archive misses or mangles the test stores - result in failed tests
  • [AMQ-3768] - ClassCastException when running some Durable Consumer test cases
  • [AMQ-3775] - KahaDB journal files retained after delay in "unsubscribing" durable subscriber from topic.
  • [AMQ-3776] - synchronization error in MessageListenerServlet.getAjaxWebClient
  • [AMQ-3777] - Incorrect variable name in bin/activemq
  • [AMQ-3780] - Non-persistent messages in the tmp-storage directory are not cleaned up when destination is deleted
  • [AMQ-3782] - FailoverTransport throws NPE
  • [AMQ-3789] - Setting java.io.tmp makes problems with some shell commands
  • [AMQ-3792] - use of the failover transport incorrectly suppresses javax.jms.InvalidClientIDException when clientId is already in use
  • [AMQ-3801] - Job scheduler can lose data on forced kill
  • [AMQ-3803] - ActiveMQWASInitialContextFactory throws ClassCastException in WebSphere 8
  • [AMQ-3804] - NullPointerException logged every 30 seconds while attempting to clear expired messages
  • [AMQ-3805] - duplicate dispatch to durable sub with concurrent send transaction commit and activate
  • [AMQ-3806] - Partial index updates can lead to bogus recovery for the vmcursor of a Q on startup
  • [AMQ-3809] - Simple ActiveMQ consumer dies on failover
  • [AMQ-3812] - activemq-core won't deploy in Karaf, missing fusesource imports
  • [AMQ-3817] - Marshalled properties don't get updated if modified during preProcessDispatch (TraceBrokerPathPlugin looks broken)
  • [AMQ-3818] - Delayed persistent messages are lost if the broker is hard killed during the delay.
  • [AMQ-3819] - high cpu with stomp+nio+ssl and many subscriptions
  • [AMQ-3823] - AMQ 5.6 Stomp v1.1 support fail to respect the spec and trims all ws from message headers
  • [AMQ-3829] - browse message may break message order
  • [AMQ-3844] - NullPointerException when removing connection info
  • [AMQ-4490] - JDBCMessageStore fails to retrieve message after 200 messages when cache is disabled
  • Improvement
  • [AMQ-498] - Secure the server from simple DoS attacks
  • [AMQ-826] - LDAP based authorization support
  • [AMQ-1514] - patch HTTP connector to support proxy authentication if proxyUsername and proxyPassword provided.
  • [AMQ-1540] - Patch to trim spaces from entry fields in web console app
  • [AMQ-1609] - STOMP messages only support properties with data type String
  • [AMQ-1891] - MySQL DB tables should be INNODB based for proper tx support.
  • [AMQ-1905] - Method required: ObjectName[] ConnectionViewMBean.getConsumers()
  • [AMQ-1906] - create ProducerViewMBean so we can see producer activity in JMX
  • [AMQ-1907] - method required: ObjectName SubscriptionViewMBean.getConnection()
  • [AMQ-2063] - JDBC persistence adapter improvements
  • [AMQ-2229] - Remove warnings from CSS file
  • [AMQ-2324] - Forwarded message cannot be distributed to the original broker
  • [AMQ-2371] - Expose the slowSubscriber attribute to JMX
  • [AMQ-2375] - Allow a group preference scheme for failover urls
  • [AMQ-2462] - New activemq-admin commands
  • [AMQ-2484] - Avoid stuck messages in a network of brokers
  • [AMQ-2504] - Synchronize time without modifying the system date.
  • [AMQ-2537] - XPath selectors doesn't work with blob messages and stream messages
  • [AMQ-2709] - Refactor core XML schema to use xs:all types in place of xs:sequence
  • [AMQ-2716] - ActiveMQConnection leaks memory by caching ActiveMQTempQueue objects
  • [AMQ-2845] - log4j conf reload via jmx ignores log4j.configuration setting
  • [AMQ-2911] - Option to make all consumers retroactive
  • [AMQ-2961] - Audit, test and update libraries in latest ActiveMQ distribution
  • [AMQ-3042] - Default broker name to be machine's hostname
  • [AMQ-3074] - Expose TransportConnection.stopping
  • [AMQ-3135] - ActiveMQ.Advisory.Connection messages should contain client ip/host
  • [AMQ-3137] - Outbound bridges should handle remote connectivity problems at startup
  • [AMQ-3164] - Upgrade the bundled service wrapper to version 3.5.7 to remove 4GB heap limitation
  • [AMQ-3208] - Add gitignore file
  • [AMQ-3227] - Support synchronous sending in ActiveMQ streams
  • [AMQ-3235] - Upgrade Camel
  • [AMQ-3242] - Change prefetch size limit for topics from 32766 to 32767
  • [AMQ-3246] - Using Ant 1.8.x to run examples causes warning in output
  • [AMQ-3247] - ensure that activemq-console command like activemq:list/activemq:query/activemq:bstat can work in servicemix container out-of-box
  • [AMQ-3248] - Allow for easy externalization of ActiveMQ configuration
  • [AMQ-3249] - Remove lib needed for JDK 1.5
  • [AMQ-3253] - Support Temporary Destinations in a network without advisories
  • [AMQ-3259] - Building with NetBeans 7.0 RC1 (w/ Maven 3.0.3) exposed malformed projects.
  • [AMQ-3260] - Javadoc refinements are necessary as exposed by the ActiveMQ build process
  • [AMQ-3263] - ActiveMQ LoggingBrokerPlugin too verbose
  • [AMQ-3268] - Cannot use tag in blueprint configuration
  • [AMQ-3297] - add xtream necessary bundles to activemq-karaf/features.xml
  • [AMQ-3300] - Add support for soWriteTimeout and soTimeout to ssl transport
  • [AMQ-3305] - Implement "exactly once" delivery with kahaDB and XA in the event of a failure post prepare
  • [AMQ-3315] - Allow socket option soLinger to be enabled on TcpTransport
  • [AMQ-3322] - Minor code improvements in security module
  • [AMQ-3323] - LDAPLoginModule - more debugging and info in exceptions
  • [AMQ-3326] - Synchronization point in RegionBroker adding and removing producers and consumers
  • [AMQ-3328] - upgrade some bundle versions for activemq-karaf feature.xml
  • [AMQ-3329] - Upgrade to use latest camel web-console in AMQ distribution
  • [AMQ-3332] - Make optimizeAckTimeout configurable to allow for different network latencies.
  • [AMQ-3335] - Allow TaskRunnerFactory to be configured on the broker via xml config
  • [AMQ-3337] - Add MBean to view Producers that are active on the Broker
  • [AMQ-3338] - Increase default maximum memory setting
  • [AMQ-3339] - Allow for an option to bound the number of GC'd Destinations when using gcInactiveDestinations=true
  • [AMQ-3340] - Allow to specify user/pass for examples
  • [AMQ-3341] - Allow reseting DestinationMap
  • [AMQ-3347] - Allow restart of network connectors
  • [AMQ-3349] - Web console tooltips should not have transparent background
  • [AMQ-3351] - Usage of the temp store index by the PList needs the be improved
  • [AMQ-3356] - DispatchedQueueCount (messages pending dispatch) should be visible on the jmx connection view
  • [AMQ-3362] - Broker does not check for expired persistent topic msgs.
  • [AMQ-3365] - pid file should contain host name
  • [AMQ-3378] - Expose isSlowConsumer for SubscriptionView
  • [AMQ-3383] - Add a string property (token) to ConnectionControl so the broker could potentially communicate a security token to a client after it authenticates
  • [AMQ-3384] - destinationFilter could be generated automatically by DemandForwardingBridgeSupport based on list of dynamicallyIncludedDestinations
  • [AMQ-3392] - Doc change to http://activemq.apache.org/javalangoutofmemory.html
  • [AMQ-3397] - Improve scalability of active durable subs with JDBC message store
  • [AMQ-3406] - Enable BrokerServiceAware support for DiscoveryAgent
  • [AMQ-3410] - AbstractAmqCommand should allow the connection factory to be changed.
  • [AMQ-3411] - Admin commands which take --amqurl should accept --user and --pass options
  • [AMQ-3412] - activemq-camel bundle dosen't need to export the package of META-INF.services.org.apache.camel
  • [AMQ-3415] - Show message timestamp in the RSS pubDate field in web console
  • [AMQ-3416] - Composite destination clarification
  • [AMQ-3431] - Guard debug logging
  • [AMQ-3436] - Support Prioritization Of Messages Pending Dispatch
  • [AMQ-3438] - Make use of remote port in Connection MBeanNames optional, useful when ephemeral range cycles quickly
  • [AMQ-3439] - NetworkConnectorViewMBean doesn't expose suppressDuplicateQueueSubscriptions and suppressDuplicateTopicSubscriptions
  • [AMQ-3442] - Use real durable sub key as MBean name for inactive durable sub and improve metrics, fix inflight count on deactivate
  • [AMQ-3449] - Add Stomp v1.1 support
  • [AMQ-3456] - Update activemq-admin usage to include info on how to change JMX access
  • [AMQ-3464] - xml view for subscribers in admin console
  • [AMQ-3467] - Replace ack locations btree with per subscriber message id range on a paged list
  • [AMQ-3468] - Update xstream to latest release v1.4.1
  • [AMQ-3475] - Stomp message frame should include a persistent header when the sent message delivery mode was persistent
  • [AMQ-3476] - Stomp 1.1 - messages sent after heart-beat timeout are lost
  • [AMQ-3482] - Make PooledConnectionFactory's sessionPool non-blocking in case its full.
  • [AMQ-3483] - Cleanup TODOs "Auto-generated catch block" to improve the quality of Tag List Report
  • [AMQ-3484] - Stomp 1.1 - add a testcase for sending messages after expired heartbeat
  • [AMQ-3486] - Add check to prevent Durable Subscriptions on Session that are in Individual Ack mode.
  • [AMQ-3496] - Provide configurable default for unqualified stomp reply-to header destination string
  • [AMQ-3499] - Raise Logging level to warn for Transport failure exceptions
  • [AMQ-3500] - Setting destination options should validate against typos
  • [AMQ-3508] - SSL and TLS - Support list of included and excluded protocols
  • [AMQ-3509] - Add the user name in the "User name or password is invalid" error line
  • [AMQ-3511] - enhance STOMP message logging so that only STOMP Frames may be redirected to another file.
  • [AMQ-3512] - Using browse command fails when a message with an array of bytes is encountered.
  • [AMQ-3520] - activemq-rar should include the slf4j log4j bridge
  • [AMQ-3521] - Update the http transport implementation from using HttpCommon v3.1 to HttpCore/HttpClient v4.x
  • [AMQ-3533] - mKahaDB, allow the directory of a filtered destination to be specified, such that destination journals can be split across disks
  • [AMQ-3541] - TimeStampingBrokerPlugin
  • [AMQ-3550] - Allow virtual topic interceptor to ignore messages that are received over network connector
  • [AMQ-3551] - exclude networkConnectors from sendFailIfNoSpace on producer flow control
  • [AMQ-3558] - Allow the base network consumer priority to be configured on a networkConnector
  • [AMQ-3566] - Enhance HTTP transport to support wire level Compression using GZip
  • [AMQ-3570] - Improve ActiveMQ's XSD to allow elements to appear in any order
  • [AMQ-3573] - Hardcoded defaults for systemUsage not suitable for out of the box
  • [AMQ-3574] - Enable configuration in activemq.xml out of the box.
  • [AMQ-3579] - Allow usage of http transport in OSGi environment
  • [AMQ-3603] - STOMP 1.1 introduced the heartBeat header implemented by the inactivity monitor, would be nice to have this option for stomp 1.0
  • [AMQ-3609] - Turn inactivity monitor thread off by default
  • [AMQ-3611] - Revert the Oracle jdbc adapter to a variant of the default jdbc adapter in place of the one supporting blobs
  • [AMQ-3613] - Rename rendezvous discovery scheme to zeroconf
  • [AMQ-3615] - Advisory broker replay of destination advisories needs to distinguish temp destination from regular destination
  • [AMQ-3619] - Enhance "create" script
  • [AMQ-3638] - Add LFU page cache as an option for kahaDB
  • [AMQ-3639] - Modify MKahaDB To Support Using One Adapter Per Destination Without Explicity Listing Every Desintation In The Configuration
  • [AMQ-3645] - Improve shall script to work better in shared-broker environment
  • [AMQ-3646] - Allow KahaDB to run without disk syncs, higher through put without the jms persistence guarantee
  • [AMQ-3652] - Typo in BrokerViewMBean javadoc
  • [AMQ-3659] - Wrapper scripts configuration needs adjusting with respect to chkconfig
  • [AMQ-3667] - Use 1G heap by default and UseDedicatedTaskRunner=false, more production ready
  • [AMQ-3682] - ActiveMQ Karaf commands should try using --jmxlocal by default
  • [AMQ-3683] - Enhance the InactivityMonitor shutdown logic
  • [AMQ-3702] - Replacing pre-jdk 1.5 syntax with jdk 1.5 syntax and other minor changes
  • [AMQ-3703] - Replace use of class Valve with standard JDK ReentrantReadWriteLock in class Topic.java
  • [AMQ-3705] - When a Destination is removed all the Advisory Topics for that destination should be removed also
  • [AMQ-3714] - getScheduler():Scheduler of class org.apache.activemq.ActiveMQConnection should use lazy initialisation
  • [AMQ-3718] - Thread pool turnover is to heavy due to Executor configuration
  • [AMQ-3720] - ActiveMqMessageConsumer should have a blocking message wait that does not require Session synchronization
  • [AMQ-3721] - StompNIOTransport doStop should check for null before calling selection.stop()
  • [AMQ-3734] - Add username info in ConnectionViewMBean and SubscriptionViewMBean
  • [AMQ-3740] - upgrade aries.transaction.manager bundle version to 0.3
  • [AMQ-3747] - Syntax errors are not showing up in the log when the broker is started in the background
  • [AMQ-3750] - Add a hint when storing a message so a message store can optimise message storage if the message is likely to be consumed quickly
  • [AMQ-3772] - Add levelDB store support to ActiveMQ
  • [AMQ-3786] - Add support for MQTT
  • [AMQ-3788] - getStatus on ActiveMQConnectionFactory is not implemented
  • [AMQ-3790] - Improve bstat command not to fail if MBean is deleted during processing
  • [AMQ-3799] - activemq-karaf features.xml should use joda-time 1.6.2 which is already a bundle
  • [AMQ-3824] - Add ability to run ActiveMQ as a service on x64 windows in 64bit JVM
  • New Feature:
  • [AMQ-512] - enhance the command line tools to allow messages on queues to be browsed, queues to be purged, messages deleted, dead letter queues to be redispatched to orginal queues etc
  • [AMQ-690] - Allow the timer to be configured (and disabled) for the async clear down of durable topic messages
  • [AMQ-1928] - Limit the maximum number of connections to a Broker
  • [AMQ-2455] - Need a facility to retry jms connections to a foreign provider by the ActiveMQ JMS bridge.
  • [AMQ-2583] - Implement stomp+nio+ssl transport
  • [AMQ-2922] - Add ability for KahaDB log files to be created on a per-destination basis.
  • [AMQ-3280] - Add support for message selectors and message headers in maven-activemq-perf-plugin.
  • [AMQ-3321] - Add kerberos authentication support for transport over https
  • [AMQ-3379] - Implement eviction strategy based on property value uniqueness
  • [AMQ-3400] - Implement new LDAP authentication module that supports wildcards
  • [AMQ-3408] - Remove inactive durable subscribers after certain timeout
  • [AMQ-3492] - enhance maven-activemq-perf-plugin to send specific message loaded from a file
  • [AMQ-3498] - Add support for setting ActiveMQ destination options in Camel endpoint uris
  • [AMQ-3519] - Allow getJMSRedelivered flag to survive a restart
  • [AMQ-3564] - new masterslave: discovery agent for networkConnector to simplify master/slave pair configuration
  • [AMQ-3623] - Add DefaultTestAppender utility abstract class
  • [AMQ-3624] - Add IP address of clients to ERROR messages created within transport layer
  • [AMQ-3632] - Allow easy creation of purely static bridges
  • [AMQ-3634] - Automatic recovery on startup when index is corrupted
  • [AMQ-3636] - Integrate stomp-websocket into web demo application
  • [AMQ-3699] - Failover transport: support priority urls
  • [AMQ-3769] - Support doing non-blocking sends that uses an async callback that gets notified when the send has been received by the broker
  • [AMQ-3820] - Exposing subscription statistics through Statistics plug-in
  • Task:
  • [AMQ-3334] - upgrade to specs 1.8.0 for activemq-karaf feature.xml
  • [AMQ-3417] - Upgrade Camel version to 2.8.0
  • [AMQ-3458] - When upgrading to Apache Camel 2.8 then use FQN class name in the TypeConverter file
  • [AMQ-3491] - Investigate and resolve LGPL dependency via camel-web
  • [AMQ-3494] - Upgrade to Camel 2.8.1
  • [AMQ-3563] - Update javadoc links to point to JDK 1.6 and JEE 1.5.
  • [AMQ-3589] - Remove @Ignore on org.apache.activemq.camel.JmsJdbcXATest
  • [AMQ-3647] - Upgrade xbean spring to 3.9
  • [AMQ-3693] - Upgrade Jetty to address CVE-2011-4461
  • [AMQ-3774] - update jdom bundle version to match Camel and ServiceMix
  • Test:
  • [AMQ-4009] - Queue length increase
  • Wish:
  • [AMQ-342] - create a security plugin using the Acegi framework
  • [AMQ-388] - JDBC support for Firebird database
  • [AMQ-1100] - BufferedTransportFilter or similar feature
  • [AMQ-1853] - Optional non-blocking redelivery
  • [AMQ-2834] - Producers blocks when global storeUsage is smaller than persistent adapter chunk size; should warn of incorrect configuration

New in Apache ActiveMQ 5.5.1 (Jul 25, 2013)

  • Bug:
  • [AMQ-3817] - Marshalled properties don't get updated if modified during preProcessDispatch (TraceBrokerPathPlugin looks broken)
  • Task:
  • [AMQ-3491] - Investigate and resolve LGPL dependency via camel-web

New in Apache ActiveMQ 5.5.0 (Jul 25, 2013)

  • Bug:
  • [AMQ-1035] - Problem with STOMP C++ Client connecting with a AMQ Broker having Authorization and Authentication Plugins installed
  • [AMQ-1604] - Please make the following configuration changes so releases into production are simpler
  • [AMQ-1780] - ActiveMQ broker does not automatically reconnect if the connection to the database is lost
  • [AMQ-1997] - Memory leak in broker - Temporary Queue related (relating to bug AMQ-1790)
  • [AMQ-2138] - Memory Leak in ActiveMQConnection
  • [AMQ-2171] - Browse queue hangs with prefetch = 0
  • [AMQ-2213] - Equals method return wrong result for TopicSession / QueueSession
  • [AMQ-2218] - Message delivery to consumer eventually pauses if consumer publishes to the same queue it receives from
  • [AMQ-2223] - Documentation References Advisory Messages which are not valid in xsd
  • [AMQ-2256] - Unnecessary TcpTransportFactory NumberFormatException and warning
  • [AMQ-2336] - Redeliveried messages stops consumers from going on consuming the rest of messages in the queue
  • [AMQ-2402] - SystemPropertiesConfiguration swaps JMX user / password
  • [AMQ-2496] - journaledJDBC not creating ACTIVEMQ_MSGS with MS SQL 2008
  • [AMQ-2633] - Missing documentation: http://activemq.apache.org/producer-flow-control.html
  • [AMQ-2662] - ActiveMQEndpointWorker.stop() sometimes is needing many minutes to shutdown
  • [AMQ-2673] - Producer started before consumer leads to a "javax.jms.JMSException: Unmatched acknowledege" (repro available)
  • [AMQ-2683] - Producer Flow Control Does Not Seem to Work with Topics
  • [AMQ-2718] - Copyright banner on page footer of ActiveMQ Console is outdated
  • [AMQ-2736] - KahaDB doesn't clean up old files
  • [AMQ-2746] - KahaDB rollback fails when connection is closed afterwards
  • [AMQ-2758] - rollback does not work on topic
  • [AMQ-2798] - Occaional hangs on ensureConnectionInfoSent
  • [AMQ-2852] - Memory leak when undeploying webapp with ActiveMQ client
  • [AMQ-2929] - Compressed text message received by consumer uncompressed
  • [AMQ-2944] - Failover transport always re-connects to the first configured transport instead of the original transport speficied in the connection url
  • [AMQ-2954] - NPE in JobSchedulerStore after restarts
  • [AMQ-2955] - Message getting stuck on queue, leading to KahaDB log files not being deleted and disk running out of space
  • [AMQ-2963] - JMSBridgeConnectors does not work with IBM MQ and ActiveMQ 5.4.0
  • [AMQ-2978] - FailoverTransport sometimes reconnects on Connection.close()
  • [AMQ-2981] - Connecting to broker using discovery protocol fails
  • [AMQ-3000] - Multiple Cron Scheduled Messages don't fire every minute as configured
  • [AMQ-3006] - STOMP connector assigns wrong default priority to incoming messages
  • [AMQ-3015] - Javascript client does not establish session properly.
  • [AMQ-3026] - Statistics plugin sample hanging when switching to http transport protocol
  • [AMQ-3033] - BrokerService leaks threads when scheduler or jmx are enabled
  • [AMQ-3036] - Scheduled message CRON strings not parsed correctly
  • [AMQ-3038] - Possible Memory-Leak as ActiveMQTempDestinations don't get deleted when ActiveMQConnection.close() is called
  • [AMQ-3040] - ConnectionState.getTempDesinations() should be renamed to ConnectionState.getTempDestinations()
  • [AMQ-3041] - TemporyQueue will never get unregisterd from JMX which leads to a memory leak
  • [AMQ-3056] - Exception when Redelivery ack is processed by topic subscription
  • [AMQ-3062] - "Deflater has been closed" exception when jms.useCompression=true and using ActiveMQBytesMessage
  • [AMQ-3067] - ActiveMQBlobMessage.copy(..) does not copy the name attribute
  • [AMQ-3068] - Error creating tables on Oracle jdbc store
  • [AMQ-3071] - ConcurrentModificationException thrown in PriorityNetworkDispatchPolicy
  • [AMQ-3075] - Auto-create database fails with PostgreSQL (Error in SQL: 'drop primary key')
  • [AMQ-3076] - spurious KahaDB warnings
  • [AMQ-3077] - ArraysIndexOutOfBoundsException : -32768 in "BrokerService[xxx] Task" thread
  • [AMQ-3081] - Durable subscriptions are not removed from mbean
  • [AMQ-3084] - Typo "DispachedCounter" in response when running activemq-admin
  • [AMQ-3085] - IndexOutOfBoundsException on FailoverTransport.updateURIs after: already known: java.net.UnknownHostException
  • [AMQ-3088] - ActiveMQ Web Console "Scheduled" Tab Invocation Fails and returns an unclear message.
  • [AMQ-3092] - Deleting a Queue from the console results in lost messages
  • [AMQ-3093] - Client should provide handling of JMSPriority messages outside of range 0-9.
  • [AMQ-3094] - ajax client does not receive all messages
  • [AMQ-3095] - Broker policyEntry DurableTopicPrefetch is ignored by default because of connection.optimizedMessageDispatch
  • [AMQ-3103] - Queue stalls after Job Scheduler component shuts down.
  • [AMQ-3115] - reportInterval property ignored by DiscardingDLQBrokerPlugin
  • [AMQ-3119] - Proxy connector stop sending messages after failover
  • [AMQ-3120] - KahaDB error: "Could not locate data file"
  • [AMQ-3122] - Recovery after out of disk space (when space freed up) needs manual intervention
  • [AMQ-3123] - ajax client receives incorrect messages when subscribed to multiple topics
  • [AMQ-3124] - Failover transport client gets corrupted connectedBrokers data
  • [AMQ-3125] - updateClusterFilter/ClientsOnRemove broken when running JMX broker
  • [AMQ-3129] - Can only have one duplex networkConnection per transportConnection
  • [AMQ-3130] - ActiveMQ's Activator not discovering other bundles with extensions.
  • [AMQ-3140] - Lost messages when scheduling messages concurrently
  • [AMQ-3141] - Messages may be lost when schedule them with a short delay
  • [AMQ-3142] - Prepare the upgrade to Karaf 2.2
  • [AMQ-3143] - JMX attribute change doesn't affect store usage
  • [AMQ-3149] - concurrentStoreAndDispatchQueues when cache disabled can lead to skipped message dispatch, leaving message pending for some time
  • [AMQ-3153] - An expired message that is consumed and resent with an updated expiration never expires again.
  • [AMQ-3160] - ConcurrentModificationException in ActiveMQ Journal Checkpoint Worker
  • [AMQ-3161] - Race condition in ActiveMQ Journal Checkpoint worker thread cleanup leads to multiple running instances
  • [AMQ-3162] - ActiveMQ checkpoint worker makes unnecessary repeated calls to Journal.getFileMap(), leading to excessive memory usage
  • [AMQ-3165] - ActiveMQ 5.4.2 Admin - Accessing Scheduled.jsp giving an Exception in log file
  • [AMQ-3167] - possible skipped Queue messages in memory limited configuration with fast consumers
  • [AMQ-3176] - Potential deadlock in duplex network connector recreation, resulting in dangling connections
  • [AMQ-3180] - JMX Browse of BytesMessage fails with javax.management.openmbean.OpenDataException: Argument's element itemValues[8]="[B@de15a0" is not a valid value for this item
  • [AMQ-3181] - ActiveMQConnectionFactory fails in an Applet enviroment
  • [AMQ-3182] - JAAS PropertiesLoginModule does not maintain internal validity state, so will commit in error after an invalid login attempt
  • [AMQ-3185] - Closing a VMTransport can cause all other VMTransports to be prematurely closed
  • [AMQ-3187] - IllegalMonitorStateException in default topic consumer of maven-activemq-perf-plugin
  • [AMQ-3190] - Durable Subscription - missing messages when selector matching sub resumes after broker restart
  • [AMQ-3193] - Consumers won't get msgs after JMX operation removeMatchingMessages() was called on a queue.
  • [AMQ-3199] - CRON next scheduled time incorrectly calculated
  • [AMQ-3200] - Scheduled CRON jobs execute twice
  • [AMQ-3202] - Sending an Empty MapMessage over HttpTransport fails with exception
  • [AMQ-3206] - Unsubscribed durable sub can leave dangling message reference in kahaDB, visible after a restart
  • [AMQ-3209] - URISupport.createURIWithQuery() fails on some composite uris.
  • [AMQ-3211] - JMSXUserId Can be spoofed by client
  • [AMQ-3220] - Wildcards do not work with included destinations for network connectors.
  • [AMQ-3222] - Failover and SimpleDiscovery - query parameters getting dropped
  • [AMQ-3238] - Topic-Messages not redelivered to durable subscription after rollback and reconnect
  • [AMQ-3585] - CLONE - ajax client does not receive all messages
  • Improvement:
  • [AMQ-2492] - Microsoft SQL Server JDBC Driver 2.0 not recognized
  • [AMQ-2968] - Add Apache commons daemon (jsvc/procrun) start/stop support.
  • [AMQ-3045] - Add property maximumRedeliveryDelay in org.apache.activemq.RedeliveryPolicy
  • [AMQ-3078] - Copyright message is out of date in admin console
  • [AMQ-3105] - Require JDK 6
  • [AMQ-3134] - Add support of MS SQL JDBC driver (version 3.0)
  • [AMQ-3138] - The Camel ActiveMQComponent should default create ActiveMQConnectionFactory with the provided broker url
  • [AMQ-3139] - Remove queue and topic endpoints in Camel when they are removed in CamelEndpointLoader
  • [AMQ-3145] - cacheEnabled attribute should be exposed on the queueview via jmx
  • [AMQ-3146] - Add original destination to Stomp messages received from DLQ
  • [AMQ-3148] - LoggingBrokerPlugin addConnection(..) log output is meaningless
  • [AMQ-3150] - Please Update log4j to latest version (1.2.16)
  • [AMQ-3159] - Log file offset in addition to file location in checkpointUpdate()
  • [AMQ-3174] - ConsumerTool (in examples) should show how to do batch acknowledgement using either transacted session or CLIENT_ACKNOWLEDGE
  • [AMQ-3175] - Allow setting soTimeout for Http/Https transports
  • [AMQ-3178] - 5.3.x clients to 5.4 brokers always get updated cluster information in the broker info, this should be configurable
  • [AMQ-3184] - Upgrade to Camel 2.6.0
  • [AMQ-3188] - Full table scan for durable subs in jdbc store when priority enabled; very slow with large message backlog
  • [AMQ-3191] - Add setTrustStore() and setKeyStore() methods to ActiveMQSslConnectionFactory class
  • [AMQ-3192] - Add setTrustStore() and setKeyStore() methods to ActiveMQSslConnectionFactory class
  • [AMQ-3195] - NetworkConnector initialization should be backed by an executor
  • [AMQ-3196] - Speed up initial message delivery for offline durable sub with keepDurableSubsActive=true and JDBC store
  • [AMQ-3197] - Virtual destinations and wildcards
  • [AMQ-3198] - Allow JAAS GuestLoginModule to fail if users specify a password
  • [AMQ-3205] - Update ActivationSpec
  • [AMQ-3207] - Various improvements to features.xml possible with karaf-2.2
  • [AMQ-3218] - Mutlitple Exclusive Consumers: It is currently not possible to always ensure that a new exclusive consumer replaces any existing one
  • [AMQ-3231] - Stomp Frame should mask passcode header in toString output, so it does not pollute the log
  • [AMQ-3237] - FileLock.tryLock() doesn't work well in all environments
  • [AMQ-3241] - "Unkown" is an incorrect spelling in ActiveMQMessageProducerSupport.java
  • [AMQ-3244] - Enable PropertiesLoginModule JAAS module to optionally cache values in memory
  • [AMQ-3348] - Ability for dynamically add, remove, start and stop network connectors
  • New Feature:
  • [AMQ-3003] - Allow the option of a DLQ per durable subscription DeadLetterStrategy
  • [AMQ-3010] - ActiveMQInputStream should allow to specify a timeout like MessageConsumer.receive() does
  • [AMQ-3107] - Fire advisory when network bridge is starter/stopped
  • [AMQ-3108] - Show network bridges in web console
  • [AMQ-3109] - Show bridges created by duplex connectors in JMX
  • [AMQ-3177] - Switch to use slf4j as logger (instad of commons logging)
  • [AMQ-3183] - Set JMSXUserID value based on authenticated principal
  • [AMQ-3186] - Allow producer and consumer throttling in maven-activemq-perf-plugin
  • [AMQ-3204] - Support non-standard destination path separators
  • [AMQ-3219] - Enable MDC logging
  • [AMQ-3236] - In the case of DLQ processing due to an exception from onMessage, provide the exception string as a message property