Red Hat AMQ 6
As of February 2025, Red Hat is no longer supporting Red Hat AMQ 6. If you are using AMQ 6, please upgrade: Migrating to AMQ 7.このコンテンツは選択した言語では利用できません。
4.2. Messaging - 6.2.0
Table 4.2, “Messaging Issues Resolved in 6.2.0” lists the issues resolved in version 6.2.0.
| Issue Number | Description |
|---|---|
| AMQ-4107 | Message order can be broken for Topic under a high load when topicPrefetch=1 and comsumer is slow |
| AMQ-4636 | JDBCPersistence DB stopped during message send; JMSException is sent back to client rather than shutting down connection |
| AMQ-4727 | Unable to add camel routes to activemq running in a karaf container |
| AMQ-4900 | With AMQP transport, Delivery Annotations are stored with the message |
| AMQ-4929 | remove old and unused org.apache.activemq.broker.BrokerService#setSupportFailOver |
| AMQ-5004 | Dispatching large messages over AMQP is very slow. |
| AMQ-5016 | BitArrayBin doesn't work well with index larger than Integer.MAX_VALUE |
| AMQ-5052 | DemandForwardingBridgeSupport has noisy log |
| AMQ-5082 | ActiveMQ replicatedLevelDB cluster breaks, all nodes stop listening |
| AMQ-5086 | vm transport create=false&waitForStart race condition |
| AMQ-5105 | leveldb fails to startup because of NoSuchMethodError |
| AMQ-5107 | In-flight queue message redelivered to multiple listeners upon broker shutdown |
| AMQ-5116 | batchStatment is misspelled for JDBC adaptors |
| AMQ-5124 | Exception logged on startup: jolokia-agent: Cannot start discovery multicast handler |
| AMQ-5125 | Broker and clients hang |
| AMQ-5126 | OnePrefetchAsyncConsumerTest fails intermittently |
| AMQ-5127 | MQTT Subscriber with QoS.EXACTLY_ONCE receives messages even after unsubscribing from topic |
| AMQ-5128 | Provide SSL_OPTS to all tasks in shell scripts |
| AMQ-5131 | Add proton META_INF/services to the activemq-osgi bundle definition so AMQP works inside Karaf |
| AMQ-5136 | MemoryUsage is not decremented on a JMS topic when rolling back a transacted session |
| AMQ-5138 | Useless code in VMTransport class |
| AMQ-5141 | Message expiry that is done as part of a removeSubscription command should not use the clients credentials. |
| AMQ-5144 | stomp+nio+ssl very slow message sending |
| AMQ-5149 | Potential deadlock |
| AMQ-5153 | LevelDB does not store subscribedDestination for durable subscriptions |
| AMQ-5155 | Heartbeat fails in STOMP over WebSockets |
| AMQ-5159 | STOMP browse gets null pointer exception if ACK mode is not AUTO |
| AMQ-5160 | Wildcard subscriptions bypass Authentication / Authorization |
| AMQ-5162 | Slave broker does not shutdown after persistence store lockout. |
| AMQ-5164 | QueueMasterSlaveSingleUrlTest.testAdvisory fails |
| AMQ-5165 | Fix destination statistics queue name |
| AMQ-5166 | MessageDatabase does not consistently apply tracker settings |
| AMQ-5167 | ActiveMQ web-console fails to start in Karaf - missing import |
| AMQ-5174 | Cannot use the JDBCIOExceptionHandler when kahadb is configured with lease-database-locker |
| AMQ-5182 | ActiveMQ web demo - chat example - Very slow on JBoss7 after AMQ-4801 |
| AMQ-5186 | AMQP producers aren't removed |
| AMQ-5187 | Virtual destination consumers do not support retroactive message recovery |
| AMQ-5193 | Java Files Started Appearing in activemq-all jar starting in 5.9.0 |
| AMQ-5195 | AMQP protocol handler doesn't set session incoming capacity |
| AMQ-5198 | MessageConsumer and Producer are not thread safe |
| AMQ-5211 | ActiveMQDestination.createDestination() should prevent empty destination name |
| AMQ-5216 | BrokerXmlConfigStartTest fails on Windows |
| AMQ-5220 | Advisory messages are still empty when received with a Stomp subscription |
| AMQ-5222 | Issue with Purge Inactive Destination feature |
| AMQ-5223 | activemq-jms-pool is missing OSGi metadata |
| AMQ-5224 | XA pooled connection factories are not recoverable |
| AMQ-5226 | When create on start is set to true, the JMS Pool can return the same connection twice in a row |
| AMQ-5233 | MQTT broker with ACL, try to connect using bad credential sends first connection event and next disconnect event to client |
| AMQ-5237 | Link stealing doesn't work for MQTT + Webscokets |
| AMQ-5242 | Most Stomp tests fail or hang on AIX |
| AMQ-5251 | Scheduler missing some synchronization |
| AMQ-5253 | Typo In settings parameter for policyEntries |
| 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-5267 | Some MQTT tests hang on HP-UX |
| AMQ-5268 | PooledConnectionFactory gets in endless loop when storing into JNDI |
| AMQ-5269 | NIO transports using blocking accept calls, very slow shutdown |
| AMQ-5277 | JDBC ack does not use messageId.entryLocator |
| AMQ-5281 | Incorrect handling of unknown values in selectors |
| AMQ-5295 | HTTPS Network Connector doesn't work with Mutual authentication- HTTPSClientTransport uses wrong SSLSocketFactory |
| AMQ-5298 | MQTT Transport can generate class cast exception when subscription is to a Virtual Topic |
| AMQ-5299 | MQTT does to calls to unsubscribe on a duplicate subscription request. |
| AMQ-5300 | Inifinite loop when attempting to replay levelDB logs to rebuild index |
| AMQ-5304 | groupClass not applied to TempDestinationAuthorizationEntry |
| AMQ-5306 | Composite destination creation in perf test always builds topics |
| AMQ-5315 | NullPointerException in DemandForwardingBridgeSupport.collectBrokerInfos |
| AMQ-5316 | LoggingBrokerPluggin, configuration variable logMessageEvents is not used |
| AMQ-5317 | NPE on brokerView addConnector |
| AMQ-5318 | JDBC store; commit called on connection that uses autocommit during "deleteAllMessages" . |
| AMQ-5320 | Incorrect Documentation in org.apache.activemq.management.SizeStatisticImpl |
| AMQ-5323 | ActiveMQ Message getProperty and setProperty inconsistent behaviour |
| AMQ-5333 | XPath selector - make xml parser features configurable |
| AMQ-5337 | Bug in ConcurrentLinkedQueue leads to excessive CPU-consumption by ActiveMQ process |
| AMQ-5345 | Improve LDAP communication |
| AMQ-5347 | persistJMSRedelivered flag doesn't work correctly when exceptions occur |
| AMQ-5350 | Separate the AMQP maxFrameSize setting from the WireFormat maxFrameSize setting. |
| AMQ-5352 | AMQP messages published transactionally should be accepted using a TransactionalState |
| AMQ-5353 | Mismatch of camel versions allowed |
| AMQ-5354 | persistJMSRedelivered feature breaks the ability for KahaDB to compact its journal files |
| AMQ-5365 | MQTT topic name in received message is wrong in network of brokers scenario |
| AMQ-5372 | UdpTransportTests fail with JDK8 in teardown |
| AMQ-5377 | Incorrect wild card replacement in mqtt topics |
| AMQ-5381 | ActiveMQBytesMessage mishandles restoration of old message contents |
| AMQ-5384 | Deadlock on DB connections in JDBCMessageStore.removeMessage |
| AMQ-5385 | MQTT Link Stealing fails when client reconnects more than once |
| AMQ-5387 | MQTT Codec - buffer mis-alignment on NIO when Back-2-Back packets are received |
| AMQ-5389 | MQTTCodec headerParser - not reducing readSize if nulls are read |
| AMQ-5390 | MQTT pending durable subscriber messages are not delievered after broker restart |
| AMQ-5394 | Incorrect handling of duplicate update message commands in KahaDB can lead to broker startup errors |
| AMQ-5395 | AmqpJMSVendor clips destination names if no prefix set |
| AMQ-5396 | Linkstealing causes deadlock when old client disconnects before link stealing adds the connection |
| AMQ-5399 | MQTT - out of order acks |
| AMQ-5401 | AMQP transport handling of durable consumer unsubscribe if incorrect |
| AMQ-5403 | remove extra expiration and timestamp manipulaton which will cause problems |
| AMQ-5407 | TransportConnector nio+ssl ignores transport.enabledProtocols settings |
| AMQ-5413 | AMQP test client delivery/redelivery anomoly |
| AMQ-5417 | Use correct classloader in TaskRunnerFactory |
| AMQ-5421 | AbortSlowAckConsumerStratagy can cause errors due to concurrent access to internal state |
| AMQ-5423 | STOMP protocol converter tracks pending ACKS but doesn't remove the state once ACK'd |
| AMQ-5431 | lack of link context when processing AMQP detach response results in NPE and stopping connection |
| AMQ-5433 | AMQP messages stuck in broker when receiver detaches while receiving |
| AMQ-5438 | Archiving mKahaDB log files cause broker restart |
| AMQ-5441 | PersistanceAdapter returns all Durable Subscriptions - this does not scale at all when durable subscribers are used |
| AMQ-5442 | NullPointerException in SimpleDiscoveryEvent on Shutdown |
| AMQ-5444 | KahaDB bug that skips doing a sync on recoveryFile |
| AMQ-5447 | Memory Leak after shutdown embeded broker with JDBC persistence |
| AMQ-5450 | mKahaDB filtered wildcard <filteredKahaDB queue="*.DLQ"> doesn't pick up myqueue.DLQ |
| AMQ-5455 | Build Failure due to missing paho dependency |
| AMQ-5456 | AMQP messages accepted transactionally by a consumer should retain the TransactionalState until commit/rollback |
| AMQ-5457 | prefetched messages go bottom in a message list of a JMX queue.browse |
| AMQ-5467 | AMQP transaction may fail to commit, or process unexpected messages, if consumer acks are not in a single unbroken sequential range |
| AMQ-5468 | AMQ MQTT doesn't reject remote connection after a long time |
| AMQ-5472 | RAR; stopped connection (due to SecurityException) not evicted from JCA pool |
| AMQ-5473 | Race condition caused by Linkstealing might make durable subs inactive |
| AMQ-5475 | AMQP transport does not send correct response to unsupported clients |
| AMQ-5476 | Batch transactions of priority messages: javax.jms.JMSException: Unmatched acknowledge: MessageAck {commandId = 14, responseRequired = false, ackType = 2, ...Could not find Message-ID XXX in dispatched-list (start of ack) |
| AMQ-5483 | LRU cached message group map eviction is not reflected in consumer assigned counts |
| AMQ-5484 | AMQP Memory leaks in the AMQP Protocol converter on sender link close |
| AMQ-5493 | KahaDB MessageDatabase race condition while stopping the broker and cleaning up |
| AMQ-5506 | typo in ZkSessionTmeout attribute of leveldb replication |
| AMQ-5511 | Retained messages for zero-byte clientId connections |
| AMQ-5513 | redelivery count incremented in error for unconsumed prefetched messages |
| AMQ-5514 | Create Release 5.10.1 |
| AMQ-5517 | Support for Jetty 9 |
| AMQ-5519 | use the "amqp:not-found" condition to indicate attempt to remove a DurableSubscription that does not exist |
| AMQ-5520 | MulticastDiscoveryAgent may use a network that is not multicast enabled, fails to startup |
| AMQ-5525 | error converting collection entry - activemq:browse karaf command via itests |
| AMQ-5534 | Generic JMS connection pool should be able to renew connections after JMSException |
| AMQ-5535 | deadlock on close and failover reconnect around org.apache.activemq.ActiveMQConnection.getScheduler |
| AMQ-5542 | KahaDB data files containing acknowledgements are deleted during cleanup |
| AMQ-5550 | Close of an AMQP consumer that failed to open because it was unauthorized causes exception in broker logs. |
| AMQ-5551 | The DiskBenchmark util doesn't sync (fsync) to disk for sync writes |
| AMQ-5563 | activemq-camel - Wrong default value in javadoc |
| AMQ-5564 | activemq-pool - Either adds new mbeans or add/remove pair of mbean for each producer in use |
| AMQ-5567 | JDBC XA - Store COMMIT FAILED: java.io.IOException: Could not remove prepared transaction state from message add for sequenceId |
| AMQ-5568 | Deleting lock file on broker shut down can take a master broker down |
| AMQ-5580 | Thread unsafe operations on the PersistenceAdapters in the mKahaDB implementation |
| AMQ-5585 | Messages not reachable after moving |
| AMQ-5594 | Virtual topic wildcard consumers don't receive some messages |
| AMQ-5598 | MQTT+NIO+SSL: Concurrent connections lead to 100% CPU usage |
| AMQ-5608 | connecting with username and SimpleAuthenticationPlugin defined without any users leads to NPE |
| AMQ-5620 | deadlock on shutdown - kahadb and local tx rollback |
| AMQ-5622 | STOMP clients can only delete durable subscriptions when clientId equals subscriptionName |
| AMQ-5626 | kahadb - inconsumable low/med priority message after restart |
| AMQ-5628 | MapMessage.getDouble uses Float when converting from String/UTF8 |
| AMQ-5629 | MapMessage.getChar does not handle if the backing map contains String or UTF8 |
| AMQ-5632 | MapMessage.getBytes crashes with NPE if no value present |
| AMQ-5644 | Autorization map doesn't handle wildcard subscriptions properly |
| AMQ-5645 | CronParser.getNextScheduledTime() for the first day of every month |
| AMQ-5647 | AMQP: Close busy receiver link to queue and open new link: new link never receives |
| AMQ-5649 | Maximum producers allowed per connection doesn't work for anonymous producers |
| AMQ-5652 | IdGenerator not optimal in port restricted enviroments. |
| AMQ-5665 | memory store is broken in 5.11.0 for advisories (and probably other issues as well) |
| AMQ-5674 | initialRedeliveryDelay not respected |
| AMQ-5680 | MessageBrokerView.getTempQueues() have test for destination.isTopic() instead of destination.isQueue() |
| AMQ-5684 | AMQP: messages get stuck |
| AMQ-5685 | Purge does not work when simple authorisation plugin is used |
| AMQ-5686 | ProxyMessageStore doesn't properly delegate |
| AMQ-5689 | Queue dispatching hangs when there are redelivered messages that don't match current consumer's selectors |
| AMQ-5697 | Authorization map doesn't handle composite destinations properly |
| AMQ-5698 | AMQP: Transport factories are not applying wireFormat.* options to newly created Transport instances. |
| AMQ-5703 | kahadb - index recovery - corrupt journal records cannot be skipped |
| AMQ-5704 | AMQP: SASL Mechanisms sent in the wrong order. |
| AMQ-5710 | ActiveMQConnection cleanup should not close the connection on the broker |
| AMQ-5711 | [AMQP] Consumer on named temporary queue results in NullPointerException |
| AMQ-5718 | Prevent adding a message to topic subscriber while we're discarding a message |
| AMQ-5721 | Update AMQ to commons-pool2 |
| AMQ-5723 | AMQP: Presettle deliveries miss calling local settle which leaks resources |
| AMQ-5724 | Query command don't filter properly |
| AMQ-5729 | Audit log shows plaintext password for QueueView.sendTextMessage |
| AMQ-5731 | AMQP: corrupted incoming frame can cause the connection to drop but not be unregistered on the Broker. |
| AMQ-5735 | increment redeliverCounter in the absence of client supplied information |
| AMQ-5738 | AMQP memory leak of sender links while closing non-durable consumers |
| AMQ-5742 | Destination dispatched count statistic not reflecting redelivery/redispatch |
| AMQ-5743 | purged of 0 messages | org.apache.activemq.broker.region.Queue logged when clearing a temp queue |
| AMQ-5744 | Password encryption is broken in OSGi |
| AMQ-5746 | Slave broker not registering JMX mBean when scheduler is enabled |
| AMQ-5752 | Move and copy message does not work in web console |
| AMQ-5758 | DefaultIOExceptionHandler causing NPE |
| AMQ-5762 | Severe memory leak in the MQTT connector |
| AMQ-5763 | Consume messages in transactions with AMQP stop after 500 messages |
| AMQ-5775 | Web console queue graph encoding |
| AMQ-5782 | Resource Adapter doesn't support SSL |
| AMQ-5783 | Failed to browse Topic: XXXXX java.io.EOFException: Chunk stream does not exist, page: y is marked free |
| AMQ-5787 | VMTransport uses broken double checked locking |
| AMQ-5793 | swiss army knife example broken |
| ENTESB-2653 | [OSE] [6.1] WARN apache.activemq.util.IdGenerator could not generate unique stub by using DNS and binding to local port: java.net.BindException Permission denied |
| ENTMQ-1010 | Memory leak possible in KahaDB when MQTT clients connect and lookup previous durable topic subscriptions |
| ENTMQ-1019 | TCK Tests multiple test failures for AMQP1.0 and JMS 1.1 |
| ENTMQ-841 | Slave broker not registering JMX mBean when scheduler is enabled |
| ENTMQ-975 | ActiveMQ split-brain after SyncFailedException on NFS filesystem |
| ENTMQ-977 | KeepAlive timer in shared file lock doesn't detect lock deletion in time |
| PROTON-833 | transport can emit frames with an invalid channel number after local session close |
| ZOOKEEPER-1751 | [ZOOKEEPER-1751] ClientCnxn#run could miss the second ping or connection get dropped before a ping |