You are viewing a plain text version of this content. The canonical link for it is here.
Posted to users@activemq.apache.org by salma ali <sa...@gmail.com> on 2015/05/12 19:51:43 UTC

Unmatched acknowledge: MessageAck

please help meeeeeeeeeeeeeeeeee
i'm using WS protocol to connect to AMQ and some times i found this
exception in AMQ  So this message not received by consumer:

javax.jms.JMSException: Unmatched acknowledge: MessageAck {commandId = 0,
responseRequired = false, ackType = 2, consumerId =
ID:QVM1-59068-1431443290141-4:1:-1:4, firstMessageId = null, lastMessageId =
ID:QVM1-59072-1431443299564-14:1:5:1:2, destination =
temp-queue://ID:QVM1-59068-1431443290141-4:1:2, transactionId = null,
messageCount = 1, poisonCause = null}; Could not find Message-ID
ID:QVM1-59072-1431443299564-14:1:5:1:2 in dispatched-list (end of ack)
	at
org.apache.activemq.broker.region.PrefetchSubscription.assertAckMatchesDispatched(PrefetchSubscription.java:481)[activemq-broker-5.11.1.jar:5.11.1]
	at
org.apache.activemq.broker.region.PrefetchSubscription.acknowledge(PrefetchSubscription.java:212)[activemq-broker-5.11.1.jar:5.11.1]
	at
org.apache.activemq.broker.region.AbstractRegion.acknowledge(AbstractRegion.java:441)[activemq-broker-5.11.1.jar:5.11.1]
	at
org.apache.activemq.broker.region.RegionBroker.acknowledge(RegionBroker.java:484)[activemq-broker-5.11.1.jar:5.11.1]
	at
org.apache.activemq.broker.BrokerFilter.acknowledge(BrokerFilter.java:87)[activemq-broker-5.11.1.jar:5.11.1]
	at
org.apache.activemq.broker.BrokerFilter.acknowledge(BrokerFilter.java:87)[activemq-broker-5.11.1.jar:5.11.1]
	at
org.apache.activemq.broker.BrokerFilter.acknowledge(BrokerFilter.java:87)[activemq-broker-5.11.1.jar:5.11.1]
	at
org.apache.activemq.broker.TransactionBroker.acknowledge(TransactionBroker.java:277)[activemq-broker-5.11.1.jar:5.11.1]
	at
org.apache.activemq.broker.MutableBrokerFilter.acknowledge(MutableBrokerFilter.java:97)[activemq-broker-5.11.1.jar:5.11.1]
	at
org.apache.activemq.broker.TransportConnection.processMessageAck(TransportConnection.java:550)[activemq-broker-5.11.1.jar:5.11.1]
	at
org.apache.activemq.command.MessageAck.visit(MessageAck.java:245)[activemq-client-5.11.1.jar:5.11.1]
	at
org.apache.activemq.broker.TransportConnection.service(TransportConnection.java:334)[activemq-broker-5.11.1.jar:5.11.1]
	at
org.apache.activemq.broker.TransportConnection$1.onCommand(TransportConnection.java:188)[activemq-broker-5.11.1.jar:5.11.1]
	at
org.apache.activemq.transport.TransportSupport.doConsume(TransportSupport.java:83)[activemq-client-5.11.1.jar:5.11.1]
	at
org.apache.activemq.transport.ws.jetty8.StompSocket.sendToActiveMQ(StompSocket.java:117)[activemq-http-5.11.1.jar:5.11.1]
	at
org.apache.activemq.transport.stomp.StompSubscription.onMessageDispatch(StompSubscription.java:78)[activemq-stomp-5.11.1.jar:5.11.1]
	at
org.apache.activemq.transport.stomp.ProtocolConverter.onActiveMQCommand(ProtocolConverter.java:870)[activemq-stomp-5.11.1.jar:5.11.1]
	at
org.apache.activemq.transport.ws.jetty8.StompSocket.oneway(StompSocket.java:109)[activemq-http-5.11.1.jar:5.11.1]
	at
org.apache.activemq.broker.TransportConnection.dispatch(TransportConnection.java:1419)[activemq-broker-5.11.1.jar:5.11.1]
	at
org.apache.activemq.broker.TransportConnection.processDispatch(TransportConnection.java:938)[activemq-broker-5.11.1.jar:5.11.1]
	at
org.apache.activemq.broker.TransportConnection.iterate(TransportConnection.java:984)[activemq-broker-5.11.1.jar:5.11.1]
	at
org.apache.activemq.thread.PooledTaskRunner.runTask(PooledTaskRunner.java:133)[activemq-client-5.11.1.jar:5.11.1]
	at
org.apache.activemq.thread.PooledTaskRunner$1.run(PooledTaskRunner.java:48)[activemq-client-5.11.1.jar:5.11.1]
	at
java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1145)[:1.7.0_17]
	at
java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:615)[:1.7.0_17]
	at java.lang.Thread.run(Thread.java:722)[:1.7.0_17]



--
View this message in context: http://activemq.2283324.n4.nabble.com/Unmatched-acknowledge-MessageAck-tp4696419.html
Sent from the ActiveMQ - User mailing list archive at Nabble.com.

Re: Unmatched acknowledge: MessageAck

Posted by salma ali <sa...@gmail.com>.
but i'm already using AMQ 5.11.1 and i have this issue (end of ack) not
(start of ack) which solved by AMQ issue 5476
lastMessageId = ID:QVM1-59072-1431443299564-14:1:5:1:2, destination =
temp-queue://ID:QVM1-59068-1431443290141-4:1:2, transactionId = null,
messageCount = 1, poisonCause = null}; Could not find Message-ID
ID:QVM1-59072-1431443299564-14:1:5:1:2 in dispatched-list (end of ack) 



--
View this message in context: http://activemq.2283324.n4.nabble.com/Unmatched-acknowledge-MessageAck-tp4696419p4696599.html
Sent from the ActiveMQ - User mailing list archive at Nabble.com.

Re: Unmatched acknowledge: MessageAck

Posted by Tim Bain <tb...@alumni.duke.edu>.
It's similar, but a) Salma's running 5.11.1 which has that fix, and b) the
bug references "start of ack" whereas this stack trace references "end of
ack".

I've been hoping Gary will throw out some insight here based on his fix for
that issue, since they could easily be very similar problems with similar
fixes.
On May 15, 2015 2:26 AM, "Tom_Z" <to...@arcor.de> wrote:

> Problably related to  https://issues.apache.org/jira/browse/AMQ-5476
> <https://issues.apache.org/jira/browse/AMQ-5476>  ? Do you use batch
> processing and different message priorities?
>
>
>
> --
> View this message in context:
> http://activemq.2283324.n4.nabble.com/Unmatched-acknowledge-MessageAck-tp4696419p4696557.html
> Sent from the ActiveMQ - User mailing list archive at Nabble.com.
>

Re: Unmatched acknowledge: MessageAck

Posted by Tom_Z <to...@arcor.de>.
Problably related to  https://issues.apache.org/jira/browse/AMQ-5476
<https://issues.apache.org/jira/browse/AMQ-5476>  ? Do you use batch
processing and different message priorities?



--
View this message in context: http://activemq.2283324.n4.nabble.com/Unmatched-acknowledge-MessageAck-tp4696419p4696557.html
Sent from the ActiveMQ - User mailing list archive at Nabble.com.