You are viewing a plain text version of this content. The canonical link for it is here.
Posted to dev@activemq.apache.org by "Rob Davies (JIRA)" <ji...@apache.org> on 2006/09/05 14:24:23 UTC

[jira] Assigned: (AMQ-575) deadlock in QueueClusterTest

     [ https://issues.apache.org/activemq/browse/AMQ-575?page=all ]

Rob Davies reassigned AMQ-575:
------------------------------

    Assignee: Rob Davies

> deadlock in QueueClusterTest
> ----------------------------
>
>                 Key: AMQ-575
>                 URL: https://issues.apache.org/activemq/browse/AMQ-575
>             Project: ActiveMQ
>          Issue Type: Bug
>          Components: Test Cases
>    Affects Versions: 4.0
>            Reporter: james strachan
>         Assigned To: Rob Davies
>             Fix For: 4.1
>
>
> here's the log
>     [junit] Running org.apache.activemq.transport.QueueClusterTest
> ^\    [junit] Full thread dump Java HotSpot(TM) Client VM (1.5.0_05-48 mixed mode, sharing):
>     [junit] 
>     [junit] "session Task" daemon prio=7 tid=0x00540cc0 nid=0x1927200 waiting for monitor entry [0xf2d49000..0xf2d4aad0]
>     [junit]     at org.apache.activemq.broker.region.Queue.dropEvent(Queue.java:263)
>     [junit]     - waiting to lock <0x1c926760> (a java.util.LinkedList)
>     [junit]     at org.apache.activemq.broker.region.QueueSubscription.acknowledge(QueueSubscription.java:55)
>     [junit]     at org.apache.activemq.broker.region.PrefetchSubscription.acknowledge(PrefetchSubscription.java:133)
>     [junit]     - locked <0x1c8c9340> (a org.apache.activemq.broker.region.QueueSubscription)
>     [junit]     at org.apache.activemq.broker.region.AbstractRegion.acknowledge(AbstractRegion.java:203)
>     [junit]     at org.apache.activemq.broker.region.RegionBroker.acknowledge(RegionBroker.java:329)
>     [junit]     at org.apache.activemq.broker.TransactionBroker.acknowledge(TransactionBroker.java:176)
>     [junit]     at org.apache.activemq.broker.BrokerFilter.acknowledge(BrokerFilter.java:59)
>     [junit]     at org.apache.activemq.broker.BrokerFilter.acknowledge(BrokerFilter.java:59)
>     [junit]     at org.apache.activemq.broker.MutableBrokerFilter.acknowledge(MutableBrokerFilter.java:71)
>     [junit]     at org.apache.activemq.broker.AbstractConnection.processMessageAck(AbstractConnection.java:342)
>     [junit]     at org.apache.activemq.command.MessageAck.visit(MessageAck.java:178)
>     [junit]     at org.apache.activemq.broker.AbstractConnection.service(AbstractConnection.java:190)
>     [junit]     at org.apache.activemq.broker.TransportConnection$1.onCommand(TransportConnection.java:60)
>     [junit]     at org.apache.activemq.transport.ResponseCorrelator.onCommand(ResponseCorrelator.java:82)
>     [junit]     at org.apache.activemq.transport.TransportFilter.onCommand(TransportFilter.java:68)
>     [junit]     at org.apache.activemq.transport.vm.VMTransport.oneway(VMTransport.java:75)
>     [junit]     at org.apache.activemq.transport.MutexTransport.oneway(MutexTransport.java:44)
>     [junit]     - locked <0x1c8180d8> (a java.lang.Object)
>     [junit]     at org.apache.activemq.transport.ResponseCorrelator.oneway(ResponseCorrelator.java:54)
>     [junit]     at org.apache.activemq.ActiveMQConnection.asyncSendPacket(ActiveMQConnection.java:1041)
>     [junit]     at org.apache.activemq.ActiveMQSession.asyncSendPacket(ActiveMQSession.java:1617)
>     [junit]     at org.apache.activemq.ActiveMQMessageConsumer.afterMessageIsConsumed(ActiveMQMessageConsumer.java:554)
>     [junit]     at org.apache.activemq.ActiveMQMessageConsumer.dispatch(ActiveMQMessageConsumer.java:716)
>     [junit]     at org.apache.activemq.ActiveMQSessionExecutor.dispatch(ActiveMQSessionExecutor.java:93)
>     [junit]     at org.apache.activemq.ActiveMQSessionExecutor.iterate(ActiveMQSessionExecutor.java:146)
>     [junit]     at org.apache.activemq.thread.SimpleTaskRunner.runTask(SimpleTaskRunner.java:110)
>     [junit]     at org.apache.activemq.thread.SimpleTaskRunner.access$100(SimpleTaskRunner.java:25)
>     [junit]     at org.apache.activemq.thread.SimpleTaskRunner$1.run(SimpleTaskRunner.java:43)
>     [junit]     at edu.emory.mathcs.backport.java.util.concurrent.ThreadPoolExecutor$Worker.runTask(ThreadPoolExecutor.java:643)
>     [junit]     at edu.emory.mathcs.backport.java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:668)
>     [junit]     at java.lang.Thread.run(Thread.java:613)
>     [junit] 
>     [junit] "tcp:///127.0.0.1:53756" daemon prio=9 tid=0x00539830 nid=0x1914400 runnable [0xf2438000..0xf2438ad0]
>     [junit]     at java.net.SocketInputStream.socketRead0(Native Method)
>     [junit]     at java.net.SocketInputStream.read(SocketInputStream.java:129)
>     [junit]     at org.apache.activemq.transport.tcp.TcpBufferedInputStream.fill(TcpBufferedInputStream.java:48)
>     [junit]     at org.apache.activemq.transport.tcp.TcpBufferedInputStream.read(TcpBufferedInputStream.java:55)
>     [junit]     at java.io.DataInputStream.readInt(DataInputStream.java:353)
>     [junit]     at org.apache.activemq.openwire.OpenWireFormat.unmarshal(OpenWireFormat.java:180)
>     [junit]     at org.apache.activemq.transport.tcp.TcpTransport.run(TcpTransport.java:135)
>     [junit]     at java.lang.Thread.run(Thread.java:613)
>     [junit] 
>     [junit] "tcp://localhost/127.0.0.1:53747" prio=5 tid=0x005394c0 nid=0x1914000 in Object.wait() [0xf23b6000..0xf23b7ad0]
>     [junit]     at java.lang.Object.wait(Native Method)
>     [junit]     - waiting on <0x1c926f00> (a java.lang.Object)
>     [junit]     at java.lang.Object.wait(Object.java:474)
>     [junit]     at org.apache.activemq.thread.Valve.turnOff(Valve.java:68)
>     [junit]     - locked <0x1c926f00> (a java.lang.Object)
>     [junit]     at org.apache.activemq.broker.region.Queue.removeSubscription(Queue.java:171)
>     [junit]     at org.apache.activemq.broker.region.AbstractRegion.removeConsumer(AbstractRegion.java:179)
>     [junit]     at org.apache.activemq.broker.region.RegionBroker.removeConsumer(RegionBroker.java:280)
>     [junit]     at org.apache.activemq.broker.BrokerFilter.removeConsumer(BrokerFilter.java:95)
>     [junit]     at org.apache.activemq.advisory.AdvisoryBroker.removeConsumer(AdvisoryBroker.java:164)
>     [junit]     at org.apache.activemq.broker.BrokerFilter.removeConsumer(BrokerFilter.java:95)
>     [junit]     at org.apache.activemq.broker.MutableBrokerFilter.removeConsumer(MutableBrokerFilter.java:107)
>     [junit]     at org.apache.activemq.broker.AbstractConnection.processRemoveConsumer(AbstractConnection.java:431)
>     [junit]     at org.apache.activemq.command.RemoveInfo.visit(RemoveInfo.java:63)
>     [junit]     at org.apache.activemq.broker.AbstractConnection.service(AbstractConnection.java:190)
>     [junit]     at org.apache.activemq.broker.TransportConnection$1.onCommand(TransportConnection.java:60)
>     [junit]     at org.apache.activemq.transport.ResponseCorrelator.onCommand(ResponseCorrelator.java:82)
>     [junit]     at org.apache.activemq.transport.TransportFilter.onCommand(TransportFilter.java:68)
>     [junit]     at org.apache.activemq.transport.vm.VMTransport.oneway(VMTransport.java:75)
>     [junit]     at org.apache.activemq.transport.MutexTransport.oneway(MutexTransport.java:44)
>     [junit]     - locked <0x1c8d0a80> (a java.lang.Object)
>     [junit]     at org.apache.activemq.transport.ResponseCorrelator.oneway(ResponseCorrelator.java:54)
>     [junit]     at org.apache.activemq.network.DemandForwardingBridge.serviceRemoteConsumerAdvisory(DemandForwardingBridge.java:331)
>     [junit]     at org.apache.activemq.network.DemandForwardingBridge.serviceRemoteCommand(DemandForwardingBridge.java:235)
>     [junit]     at org.apache.activemq.network.DemandForwardingBridge$2.onCommand(DemandForwardingBridge.java:121)
>     [junit]     at org.apache.activemq.transport.ResponseCorrelator.onCommand(ResponseCorrelator.java:82)
>     [junit]     at org.apache.activemq.transport.TransportFilter.onCommand(TransportFilter.java:68)
>     [junit]     at org.apache.activemq.transport.failover.FailoverTransport$1.onCommand(FailoverTransport.java:103)
>     [junit]     at org.apache.activemq.transport.WireFormatNegotiator.onCommand(WireFormatNegotiator.java:105)
>     [junit]     at org.apache.activemq.transport.TransportSupport.doConsume(TransportSupport.java:77)
>     [junit]     at org.apache.activemq.transport.tcp.TcpTransport.run(TcpTransport.java:136)
>     [junit]     at java.lang.Thread.run(Thread.java:613)
>     [junit] 
>     [junit] "tcp://localhost/127.0.0.1:53747" prio=5 tid=0x005390f0 nid=0x1913c00 in Object.wait() [0xf1b26000..0xf1b26ad0]
>     [junit]     at java.lang.Object.wait(Native Method)
>     [junit]     - waiting on <0x1c8629b8> (a edu.emory.mathcs.backport.java.util.concurrent.CountDownLatch)
>     [junit]     at java.lang.Object.wait(Object.java:474)
>     [junit]     at edu.emory.mathcs.backport.java.util.concurrent.CountDownLatch.await(CountDownLatch.java:173)
>     [junit]     - locked <0x1c8629b8> (a edu.emory.mathcs.backport.java.util.concurrent.CountDownLatch)
>     [junit]     at org.apache.activemq.network.DemandForwardingBridge.waitStarted(DemandForwardingBridge.java:481)
>     [junit]     at org.apache.activemq.network.DemandForwardingBridge.serviceRemoteCommand(DemandForwardingBridge.java:250)
>     [junit]     - locked <0x1c862a40> (a java.lang.Object)
>     [junit]     at org.apache.activemq.network.DemandForwardingBridge$2.onCommand(DemandForwardingBridge.java:121)
>     [junit]     at org.apache.activemq.transport.ResponseCorrelator.onCommand(ResponseCorrelator.java:82)
>     [junit]     at org.apache.activemq.transport.TransportFilter.onCommand(TransportFilter.java:68)
>     [junit]     at org.apache.activemq.transport.failover.FailoverTransport$1.onCommand(FailoverTransport.java:103)
>     [junit]     at org.apache.activemq.transport.WireFormatNegotiator.onCommand(WireFormatNegotiator.java:105)
>     [junit]     at org.apache.activemq.transport.TransportSupport.doConsume(TransportSupport.java:77)
>     [junit]     at org.apache.activemq.transport.tcp.TcpTransport.run(TcpTransport.java:136)
>     [junit]     at java.lang.Thread.run(Thread.java:613)
>     [junit] 
>     [junit] "tcp:///127.0.0.1:53755" daemon prio=9 tid=0x00538e90 nid=0x1912800 runnable [0xf22b5000..0xf22b5ad0]
>     [junit]     at java.net.SocketInputStream.socketRead0(Native Method)
>     [junit]     at java.net.SocketInputStream.read(SocketInputStream.java:129)
>     [junit]     at org.apache.activemq.transport.tcp.TcpBufferedInputStream.fill(TcpBufferedInputStream.java:48)
>     [junit]     at org.apache.activemq.transport.tcp.TcpBufferedInputStream.read(TcpBufferedInputStream.java:55)
>     [junit]     at java.io.DataInputStream.readInt(DataInputStream.java:353)
>     [junit]     at org.apache.activemq.openwire.OpenWireFormat.unmarshal(OpenWireFormat.java:180)
>     [junit]     at org.apache.activemq.transport.tcp.TcpTransport.run(TcpTransport.java:135)
>     [junit]     at java.lang.Thread.run(Thread.java:613)
>     [junit] 
>     [junit] "tcp://localhost/127.0.0.1:53749" prio=5 tid=0x00538a00 nid=0x1912400 in Object.wait() [0xf2234000..0xf2234ad0]
>     [junit]     at java.lang.Object.wait(Native Method)
>     [junit]     - waiting on <0x1c862b60> (a edu.emory.mathcs.backport.java.util.concurrent.CountDownLatch)
>     [junit]     at java.lang.Object.wait(Object.java:474)
>     [junit]     at edu.emory.mathcs.backport.java.util.concurrent.CountDownLatch.await(CountDownLatch.java:173)
>     [junit]     - locked <0x1c862b60> (a edu.emory.mathcs.backport.java.util.concurrent.CountDownLatch)
>     [junit]     at org.apache.activemq.network.DemandForwardingBridge.waitStarted(DemandForwardingBridge.java:481)
>     [junit]     at org.apache.activemq.network.DemandForwardingBridge.serviceRemoteCommand(DemandForwardingBridge.java:250)
>     [junit]     - locked <0x1c862be8> (a java.lang.Object)
>     [junit]     at org.apache.activemq.network.DemandForwardingBridge$2.onCommand(DemandForwardingBridge.java:121)
>     [junit]     at org.apache.activemq.transport.ResponseCorrelator.onCommand(ResponseCorrelator.java:82)
>     [junit]     at org.apache.activemq.transport.TransportFilter.onCommand(TransportFilter.java:68)
>     [junit]     at org.apache.activemq.transport.failover.FailoverTransport$1.onCommand(FailoverTransport.java:103)
>     [junit]     at org.apache.activemq.transport.WireFormatNegotiator.onCommand(WireFormatNegotiator.java:105)
>     [junit]     at org.apache.activemq.transport.TransportSupport.doConsume(TransportSupport.java:77)
>     [junit]     at org.apache.activemq.transport.tcp.TcpTransport.run(TcpTransport.java:136)
>     [junit]     at java.lang.Thread.run(Thread.java:613)
>     [junit] 
>     [junit] "tcp:///127.0.0.1:53754" daemon prio=9 tid=0x005383d0 nid=0x1850e00 runnable [0xf20b1000..0xf20b1ad0]
>     [junit]     at java.net.SocketInputStream.socketRead0(Native Method)
>     [junit]     at java.net.SocketInputStream.read(SocketInputStream.java:129)
>     [junit]     at org.apache.activemq.transport.tcp.TcpBufferedInputStream.fill(TcpBufferedInputStream.java:48)
>     [junit]     at org.apache.activemq.transport.tcp.TcpBufferedInputStream.read(TcpBufferedInputStream.java:55)
>     [junit]     at java.io.DataInputStream.readInt(DataInputStream.java:353)
>     [junit]     at org.apache.activemq.openwire.OpenWireFormat.unmarshal(OpenWireFormat.java:180)
>     [junit]     at org.apache.activemq.transport.tcp.TcpTransport.run(TcpTransport.java:135)
>     [junit]     at java.lang.Thread.run(Thread.java:613)
>     [junit] 
>     [junit] "tcp:///127.0.0.1:53753" daemon prio=9 tid=0x005362f0 nid=0x182a200 runnable [0xf1f2e000..0xf1f2ead0]
>     [junit]     at java.net.SocketInputStream.socketRead0(Native Method)
>     [junit]     at java.net.SocketInputStream.read(SocketInputStream.java:129)
>     [junit]     at org.apache.activemq.transport.tcp.TcpBufferedInputStream.fill(TcpBufferedInputStream.java:48)
>     [junit]     at org.apache.activemq.transport.tcp.TcpBufferedInputStream.read(TcpBufferedInputStream.java:55)
>     [junit]     at java.io.DataInputStream.readInt(DataInputStream.java:353)
>     [junit]     at org.apache.activemq.openwire.OpenWireFormat.unmarshal(OpenWireFormat.java:180)
>     [junit]     at org.apache.activemq.transport.tcp.TcpTransport.run(TcpTransport.java:135)
>     [junit]     at java.lang.Thread.run(Thread.java:613)
>     [junit] 
>     [junit] "tcp://localhost/127.0.0.1:53745" prio=5 tid=0x00537340 nid=0x1916400 waiting for monitor entry [0xf21b2000..0xf21b3ad0]
>     [junit]     at org.apache.activemq.broker.region.PrefetchSubscription.add(PrefetchSubscription.java:58)
>     [junit]     - waiting to lock <0x1c8c9340> (a org.apache.activemq.broker.region.QueueSubscription)
>     [junit]     at org.apache.activemq.broker.region.QueueSubscription.add(QueueSubscription.java:38)
>     [junit]     at org.apache.activemq.broker.region.policy.RoundRobinDispatchPolicy.dispatch(RoundRobinDispatchPolicy.java:53)
>     [junit]     - locked <0x1c926f28> (a edu.emory.mathcs.backport.java.util.concurrent.CopyOnWriteArrayList)
>     [junit]     at org.apache.activemq.broker.region.Queue.removeSubscription(Queue.java:210)
>     [junit]     - locked <0x1c926760> (a java.util.LinkedList)
>     [junit]     at org.apache.activemq.broker.region.AbstractRegion.removeConsumer(AbstractRegion.java:179)
>     [junit]     at org.apache.activemq.broker.region.RegionBroker.removeConsumer(RegionBroker.java:280)
>     [junit]     at org.apache.activemq.broker.BrokerFilter.removeConsumer(BrokerFilter.java:95)
>     [junit]     at org.apache.activemq.advisory.AdvisoryBroker.removeConsumer(AdvisoryBroker.java:164)
>     [junit]     at org.apache.activemq.broker.BrokerFilter.removeConsumer(BrokerFilter.java:95)
>     [junit]     at org.apache.activemq.broker.MutableBrokerFilter.removeConsumer(MutableBrokerFilter.java:107)
>     [junit]     at org.apache.activemq.broker.AbstractConnection.processRemoveConsumer(AbstractConnection.java:431)
>     [junit]     at org.apache.activemq.command.RemoveInfo.visit(RemoveInfo.java:63)
>     [junit]     at org.apache.activemq.broker.AbstractConnection.service(AbstractConnection.java:190)
>     [junit]     at org.apache.activemq.broker.TransportConnection$1.onCommand(TransportConnection.java:60)
>     [junit]     at org.apache.activemq.transport.ResponseCorrelator.onCommand(ResponseCorrelator.java:82)
>     [junit]     at org.apache.activemq.transport.TransportFilter.onCommand(TransportFilter.java:68)
>     [junit]     at org.apache.activemq.transport.vm.VMTransport.oneway(VMTransport.java:75)
>     [junit]     at org.apache.activemq.transport.MutexTransport.oneway(MutexTransport.java:44)
>     [junit]     - locked <0x1c80aac8> (a java.lang.Object)
>     [junit]     at org.apache.activemq.transport.ResponseCorrelator.oneway(ResponseCorrelator.java:54)
>     [junit]     at org.apache.activemq.network.DemandForwardingBridge.serviceRemoteConsumerAdvisory(DemandForwardingBridge.java:331)
>     [junit]     at org.apache.activemq.network.DemandForwardingBridge.serviceRemoteCommand(DemandForwardingBridge.java:235)
>     [junit]     at org.apache.activemq.network.DemandForwardingBridge$2.onCommand(DemandForwardingBridge.java:121)
>     [junit]     at org.apache.activemq.transport.ResponseCorrelator.onCommand(ResponseCorrelator.java:82)
>     [junit]     at org.apache.activemq.transport.TransportFilter.onCommand(TransportFilter.java:68)
>     [junit]     at org.apache.activemq.transport.failover.FailoverTransport$1.onCommand(FailoverTransport.java:103)
>     [junit]     at org.apache.activemq.transport.WireFormatNegotiator.onCommand(WireFormatNegotiator.java:105)
>     [junit]     at org.apache.activemq.transport.TransportSupport.doConsume(TransportSupport.java:77)
>     [junit]     at org.apache.activemq.transport.tcp.TcpTransport.run(TcpTransport.java:136)
>     [junit]     at java.lang.Thread.run(Thread.java:613)
>     [junit] 
>     [junit] "tcp://localhost/127.0.0.1:53745" prio=5 tid=0x00536f80 nid=0x1843c00 runnable [0xf2132000..0xf2132ad0]
>     [junit]     at java.net.SocketInputStream.socketRead0(Native Method)
>     [junit]     at java.net.SocketInputStream.read(SocketInputStream.java:129)
>     [junit]     at org.apache.activemq.transport.tcp.TcpBufferedInputStream.fill(TcpBufferedInputStream.java:48)
>     [junit]     at org.apache.activemq.transport.tcp.TcpBufferedInputStream.read(TcpBufferedInputStream.java:55)
>     [junit]     at java.io.DataInputStream.readInt(DataInputStream.java:353)
>     [junit]     at org.apache.activemq.openwire.OpenWireFormat.unmarshal(OpenWireFormat.java:180)
>     [junit]     at org.apache.activemq.transport.tcp.TcpTransport.run(TcpTransport.java:135)
>     [junit]     at java.lang.Thread.run(Thread.java:613)
>     [junit] 
>     [junit] "tcp:///127.0.0.1:53752" daemon prio=9 tid=0x00533fe0 nid=0x190ec00 runnable [0xf1ca9000..0xf1ca9ad0]
>     [junit]     at java.net.SocketInputStream.socketRead0(Native Method)
>     [junit]     at java.net.SocketInputStream.read(SocketInputStream.java:129)
>     [junit]     at org.apache.activemq.transport.tcp.TcpBufferedInputStream.fill(TcpBufferedInputStream.java:48)
>     [junit]     at org.apache.activemq.transport.tcp.TcpBufferedInputStream.read(TcpBufferedInputStream.java:55)
>     [junit]     at java.io.DataInputStream.readInt(DataInputStream.java:353)
>     [junit]     at org.apache.activemq.openwire.OpenWireFormat.unmarshal(OpenWireFormat.java:180)
>     [junit]     at org.apache.activemq.transport.tcp.TcpTransport.run(TcpTransport.java:135)
>     [junit]     at java.lang.Thread.run(Thread.java:613)
>     [junit] 
>     [junit] "ActiveMQ Default Thread Pool Thread" daemon prio=5 tid=0x00536450 nid=0x182b600 in Object.wait() [0xf1faf000..0xf1fafad0]
>     [junit]     at java.lang.Object.wait(Native Method)
>     [junit]     - waiting on <0x1c4a8840> (a java.lang.Object)
>     [junit]     at java.lang.Object.wait(Object.java:474)
>     [junit]     at edu.emory.mathcs.backport.java.util.concurrent.DelayQueue.take(DelayQueue.java:152)
>     [junit]     - locked <0x1c4a8840> (a java.lang.Object)
>     [junit]     at edu.emory.mathcs.backport.java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:470)
>     [junit]     at edu.emory.mathcs.backport.java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:667)
>     [junit]     at java.lang.Thread.run(Thread.java:613)
>     [junit] 
>     [junit] "Transport Status Dector org.apache.activemq.broker.TransportConnector@dc0dd8" daemon prio=9 tid=0x00534f90 nid=0x18b8c00 waiting on condition [0xf18a1000..0xf18a1ad0]
>     [junit]     at java.lang.Thread.sleep(Native Method)
>     [junit]     at org.apache.activemq.broker.TransportStatusDetector.run(TransportStatusDetector.java:98)
>     [junit]     at java.lang.Thread.run(Thread.java:613)
>     [junit] 
>     [junit] "tcp:///127.0.0.1:53751" daemon prio=9 tid=0x00536050 nid=0x1828e00 in Object.wait() [0xf1eac000..0xf1eadad0]
>     [junit]     at java.lang.Object.wait(Native Method)
>     [junit]     - waiting on <0x1c926f00> (a java.lang.Object)
>     [junit]     at java.lang.Object.wait(Object.java:474)
>     [junit]     at org.apache.activemq.thread.Valve.increment(Valve.java:88)
>     [junit]     - locked <0x1c926f00> (a java.lang.Object)
>     [junit]     at org.apache.activemq.broker.region.Queue.dispatch(Queue.java:364)
>     [junit]     at org.apache.activemq.broker.region.Queue.send(Queue.java:245)
>     [junit]     at org.apache.activemq.broker.region.AbstractRegion.send(AbstractRegion.java:195)
>     [junit]     at org.apache.activemq.broker.region.RegionBroker.send(RegionBroker.java:309)
>     [junit]     at org.apache.activemq.broker.TransactionBroker.send(TransactionBroker.java:192)
>     [junit]     at org.apache.activemq.broker.BrokerFilter.send(BrokerFilter.java:107)
>     [junit]     at org.apache.activemq.broker.CompositeDestinationBroker.send(CompositeDestinationBroker.java:97)
>     [junit]     at org.apache.activemq.broker.MutableBrokerFilter.send(MutableBrokerFilter.java:119)
>     [junit]     at org.apache.activemq.broker.AbstractConnection.processMessage(AbstractConnection.java:337)
>     [junit]     at org.apache.activemq.command.ActiveMQMessage.visit(ActiveMQMessage.java:508)
>     [junit]     at org.apache.activemq.broker.AbstractConnection.service(AbstractConnection.java:190)
>     [junit]     at org.apache.activemq.broker.TransportConnection$1.onCommand(TransportConnection.java:60)
>     [junit]     at org.apache.activemq.transport.ResponseCorrelator.onCommand(ResponseCorrelator.java:82)
>     [junit]     at org.apache.activemq.transport.TransportFilter.onCommand(TransportFilter.java:68)
>     [junit]     at org.apache.activemq.transport.WireFormatNegotiator.onCommand(WireFormatNegotiator.java:105)
>     [junit]     at org.apache.activemq.transport.TransportSupport.doConsume(TransportSupport.java:77)
>     [junit]     at org.apache.activemq.transport.tcp.TcpTransport.run(TcpTransport.java:136)
>     [junit]     at java.lang.Thread.run(Thread.java:613)
>     [junit] 
>     [junit] "tcp://localhost/127.0.0.1:53749" prio=5 tid=0x00535aa0 nid=0x190d800 runnable [0xf1e2c000..0xf1e2cad0]
>     [junit]     at java.net.SocketInputStream.socketRead0(Native Method)
>     [junit]     at java.net.SocketInputStream.read(SocketInputStream.java:129)
>     [junit]     at org.apache.activemq.transport.tcp.TcpBufferedInputStream.fill(TcpBufferedInputStream.java:48)
>     [junit]     at org.apache.activemq.transport.tcp.TcpBufferedInputStream.read(TcpBufferedInputStream.java:55)
>     [junit]     at java.io.DataInputStream.readInt(DataInputStream.java:353)
>     [junit]     at org.apache.activemq.openwire.OpenWireFormat.unmarshal(OpenWireFormat.java:180)
>     [junit]     at org.apache.activemq.transport.tcp.TcpTransport.run(TcpTransport.java:135)
>     [junit]     at java.lang.Thread.run(Thread.java:613)
>     [junit] 
>     [junit] "tcp://localhost/127.0.0.1:53749" prio=5 tid=0x00535600 nid=0x190d400 runnable [0xf1dab000..0xf1dabad0]
>     [junit]     at java.net.SocketInputStream.socketRead0(Native Method)
>     [junit]     at java.net.SocketInputStream.read(SocketInputStream.java:129)
>     [junit]     at org.apache.activemq.transport.tcp.TcpBufferedInputStream.fill(TcpBufferedInputStream.java:48)
>     [junit]     at org.apache.activemq.transport.tcp.TcpBufferedInputStream.read(TcpBufferedInputStream.java:55)
>     [junit]     at java.io.DataInputStream.readInt(DataInputStream.java:353)
>     [junit]     at org.apache.activemq.openwire.OpenWireFormat.unmarshal(OpenWireFormat.java:180)
>     [junit]     at org.apache.activemq.transport.tcp.TcpTransport.run(TcpTransport.java:135)
>     [junit]     at java.lang.Thread.run(Thread.java:613)
>     [junit] 
>     [junit] "MulticastDiscovery: null" daemon prio=5 tid=0x00535360 nid=0x190f000 runnable [0xf1d2a000..0xf1d2aad0]
>     [junit]     at java.net.PlainDatagramSocketImpl.receive0(Native Method)
>     [junit]     at java.net.PlainDatagramSocketImpl.receive(PlainDatagramSocketImpl.java:136)
>     [junit]     - locked <0x1c6d2ef0> (a java.net.PlainDatagramSocketImpl)
>     [junit]     at java.net.DatagramSocket.receive(DatagramSocket.java:712)
>     [junit]     - locked <0x1c6dff50> (a java.net.DatagramPacket)
>     [junit]     - locked <0x1c6d0800> (a java.net.MulticastSocket)
>     [junit]     at org.apache.activemq.transport.discovery.multicast.MulticastDiscoveryAgent.run(MulticastDiscoveryAgent.java:239)
>     [junit]     at java.lang.Thread.run(Thread.java:613)
>     [junit] 
>     [junit] "tcp:///127.0.0.1:53750" daemon prio=9 tid=0x00534cf0 nid=0x1851600 in Object.wait() [0xf1c27000..0xf1c28ad0]
>     [junit]     at java.lang.Object.wait(Native Method)
>     [junit]     - waiting on <0x1c926f00> (a java.lang.Object)
>     [junit]     at java.lang.Object.wait(Object.java:474)
>     [junit]     at org.apache.activemq.thread.Valve.increment(Valve.java:88)
>     [junit]     - locked <0x1c926f00> (a java.lang.Object)
>     [junit]     at org.apache.activemq.broker.region.Queue.dispatch(Queue.java:364)
>     [junit]     at org.apache.activemq.broker.region.Queue.send(Queue.java:245)
>     [junit]     at org.apache.activemq.broker.region.AbstractRegion.send(AbstractRegion.java:195)
>     [junit]     at org.apache.activemq.broker.region.RegionBroker.send(RegionBroker.java:309)
>     [junit]     at org.apache.activemq.broker.TransactionBroker.send(TransactionBroker.java:192)
>     [junit]     at org.apache.activemq.broker.BrokerFilter.send(BrokerFilter.java:107)
>     [junit]     at org.apache.activemq.broker.CompositeDestinationBroker.send(CompositeDestinationBroker.java:97)
>     [junit]     at org.apache.activemq.broker.MutableBrokerFilter.send(MutableBrokerFilter.java:119)
>     [junit]     at org.apache.activemq.broker.AbstractConnection.processMessage(AbstractConnection.java:337)
>     [junit]     at org.apache.activemq.command.ActiveMQMessage.visit(ActiveMQMessage.java:508)
>     [junit]     at org.apache.activemq.broker.AbstractConnection.service(AbstractConnection.java:190)
>     [junit]     at org.apache.activemq.broker.TransportConnection$1.onCommand(TransportConnection.java:60)
>     [junit]     at org.apache.activemq.transport.ResponseCorrelator.onCommand(ResponseCorrelator.java:82)
>     [junit]     at org.apache.activemq.transport.TransportFilter.onCommand(TransportFilter.java:68)
>     [junit]     at org.apache.activemq.transport.WireFormatNegotiator.onCommand(WireFormatNegotiator.java:105)
>     [junit]     at org.apache.activemq.transport.TransportSupport.doConsume(TransportSupport.java:77)
>     [junit]     at org.apache.activemq.transport.tcp.TcpTransport.run(TcpTransport.java:136)
>     [junit]     at java.lang.Thread.run(Thread.java:613)
>     [junit] 
>     [junit] "ActiveMQ Default Thread Pool Thread" daemon prio=5 tid=0x00534280 nid=0x1851200 in Object.wait() [0xf1ba7000..0xf1ba7ad0]
>     [junit]     at java.lang.Object.wait(Native Method)
>     [junit]     - waiting on <0x1c4a8840> (a java.lang.Object)
>     [junit]     at java.lang.Object.wait(Object.java:474)
>     [junit]     at edu.emory.mathcs.backport.java.util.concurrent.DelayQueue.take(DelayQueue.java:152)
>     [junit]     - locked <0x1c4a8840> (a java.lang.Object)
>     [junit]     at edu.emory.mathcs.backport.java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:470)
>     [junit]     at edu.emory.mathcs.backport.java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:667)
>     [junit]     at java.lang.Thread.run(Thread.java:613)
>     [junit] 
>     [junit] "ActiveMQ Default Thread Pool Thread" daemon prio=5 tid=0x00533d40 nid=0x1850a00 in Object.wait() [0xf1aa5000..0xf1aa5ad0]
>     [junit]     at java.lang.Object.wait(Native Method)
>     [junit]     - waiting on <0x1c4a8840> (a java.lang.Object)
>     [junit]     at java.lang.Object.wait(Object.java:474)
>     [junit]     at edu.emory.mathcs.backport.java.util.concurrent.DelayQueue.take(DelayQueue.java:152)
>     [junit]     - locked <0x1c4a8840> (a java.lang.Object)
>     [junit]     at edu.emory.mathcs.backport.java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:470)
>     [junit]     at edu.emory.mathcs.backport.java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:667)
>     [junit]     at java.lang.Thread.run(Thread.java:613)
>     [junit] 
>     [junit] "Transport Status Dector org.apache.activemq.broker.TransportConnector@c47680" daemon prio=9 tid=0x005337f0 nid=0x1850600 waiting on condition [0xf1a24000..0xf1a24ad0]
>     [junit]     at java.lang.Thread.sleep(Native Method)
>     [junit]     at org.apache.activemq.broker.TransportStatusDetector.run(TransportStatusDetector.java:98)
>     [junit]     at java.lang.Thread.run(Thread.java:613)
>     [junit] 
>     [junit] "MulticastDiscovery: tcp://bigmac-6.local:53749" daemon prio=5 tid=0x00533380 nid=0x1850200 runnable [0xf19a3000..0xf19a3ad0]
>     [junit]     at java.net.PlainDatagramSocketImpl.receive0(Native Method)
>     [junit]     at java.net.PlainDatagramSocketImpl.receive(PlainDatagramSocketImpl.java:136)
>     [junit]     - locked <0x1c64c530> (a java.net.PlainDatagramSocketImpl)
>     [junit]     at java.net.DatagramSocket.receive(DatagramSocket.java:712)
>     [junit]     - locked <0x1c64c570> (a java.net.DatagramPacket)
>     [junit]     - locked <0x1c64c590> (a java.net.MulticastSocket)
>     [junit]     at org.apache.activemq.transport.discovery.multicast.MulticastDiscoveryAgent.run(MulticastDiscoveryAgent.java:239)
>     [junit]     at java.lang.Thread.run(Thread.java:613)
>     [junit] 
>     [junit] "TcpTransportServer@tcp://bigmac-6.local:53749" daemon prio=9 tid=0x00532f90 nid=0x1851a00 runnable [0xf1922000..0xf1922ad0]
>     [junit]     at java.net.PlainSocketImpl.socketAccept(Native Method)
>     [junit]     at java.net.PlainSocketImpl.accept(PlainSocketImpl.java:384)
>     [junit]     - locked <0x1c6d1928> (a java.net.SocksSocketImpl)
>     [junit]     at java.net.ServerSocket.implAccept(ServerSocket.java:450)
>     [junit]     at java.net.ServerSocket.accept(ServerSocket.java:421)
>     [junit]     at org.apache.activemq.transport.tcp.TcpTransportServer.run(TcpTransportServer.java:96)
>     [junit]     at java.lang.Thread.run(Thread.java:613)
>     [junit] 
>     [junit] "ActiveMQ Scheduler" daemon prio=5 tid=0x00532a00 nid=0x18b8800 in Object.wait() [0xf1820000..0xf1820ad0]
>     [junit]     at java.lang.Object.wait(Native Method)
>     [junit]     - waiting on <0x1c3d6210> (a java.lang.Object)
>     [junit]     at java.lang.Object.wait(Object.java:432)
>     [junit]     at edu.emory.mathcs.backport.java.util.concurrent.TimeUnit.timedWait(TimeUnit.java:294)
>     [junit]     at edu.emory.mathcs.backport.java.util.concurrent.DelayQueue.take(DelayQueue.java:156)
>     [junit]     - locked <0x1c3d6210> (a java.lang.Object)
>     [junit]     at edu.emory.mathcs.backport.java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:470)
>     [junit]     at edu.emory.mathcs.backport.java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:667)
>     [junit]     at java.lang.Thread.run(Thread.java:613)
>     [junit] 
>     [junit] "tcp://localhost/127.0.0.1:53747" prio=5 tid=0x00530620 nid=0x18b9600 runnable [0xf179f000..0xf179fad0]
>     [junit]     at java.net.SocketInputStream.socketRead0(Native Method)
>     [junit]     at java.net.SocketInputStream.read(SocketInputStream.java:129)
>     [junit]     at org.apache.activemq.transport.tcp.TcpBufferedInputStream.fill(TcpBufferedInputStream.java:48)
>     [junit]     at org.apache.activemq.transport.tcp.TcpBufferedInputStream.read(TcpBufferedInputStream.java:55)
>     [junit]     at java.io.DataInputStream.readInt(DataInputStream.java:353)
>     [junit]     at org.apache.activemq.openwire.OpenWireFormat.unmarshal(OpenWireFormat.java:180)
>     [junit]     at org.apache.activemq.transport.tcp.TcpTransport.run(TcpTransport.java:135)
>     [junit]     at java.lang.Thread.run(Thread.java:613)
>     [junit] 
>     [junit] "tcp:///127.0.0.1:53748" daemon prio=9 tid=0x00530250 nid=0x18b9200 runnable [0xf171e000..0xf171ead0]
>     [junit]     at java.net.SocketInputStream.socketRead0(Native Method)
>     [junit]     at java.net.SocketInputStream.read(SocketInputStream.java:129)
>     [junit]     at org.apache.activemq.transport.tcp.TcpBufferedInputStream.fill(TcpBufferedInputStream.java:48)
>     [junit]     at org.apache.activemq.transport.tcp.TcpBufferedInputStream.read(TcpBufferedInputStream.java:55)
>     [junit]     at java.io.DataInputStream.readInt(DataInputStream.java:353)
>     [junit]     at org.apache.activemq.openwire.OpenWireFormat.unmarshal(OpenWireFormat.java:180)
>     [junit]     at org.apache.activemq.transport.tcp.TcpTransport.run(TcpTransport.java:135)
>     [junit]     at java.lang.Thread.run(Thread.java:613)
>     [junit] 
>     [junit] "Transport Status Dector org.apache.activemq.broker.TransportConnector@d03b5b" daemon prio=9 tid=0x0052ff30 nid=0x18b8400 waiting on condition [0xf169d000..0xf169dad0]
>     [junit]     at java.lang.Thread.sleep(Native Method)
>     [junit]     at org.apache.activemq.broker.TransportStatusDetector.run(TransportStatusDetector.java:98)
>     [junit]     at java.lang.Thread.run(Thread.java:613)
>     [junit] 
>     [junit] "ActiveMQ Default Thread Pool Thread" daemon prio=5 tid=0x0052f8e0 nid=0x18c6e00 in Object.wait() [0xf161c000..0xf161cad0]
>     [junit]     at java.lang.Object.wait(Native Method)
>     [junit]     - waiting on <0x1c4a8840> (a java.lang.Object)
>     [junit]     at java.lang.Object.wait(Object.java:474)
>     [junit]     at edu.emory.mathcs.backport.java.util.concurrent.DelayQueue.take(DelayQueue.java:152)
>     [junit]     - locked <0x1c4a8840> (a java.lang.Object)
>     [junit]     at edu.emory.mathcs.backport.java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:470)
>     [junit]     at edu.emory.mathcs.backport.java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:667)
>     [junit]     at java.lang.Thread.run(Thread.java:613)
>     [junit] 
>     [junit] "MulticastDiscovery: null" daemon prio=5 tid=0x0052f640 nid=0x18c6a00 runnable [0xf159b000..0xf159bad0]
>     [junit]     at java.net.PlainDatagramSocketImpl.receive0(Native Method)
>     [junit]     at java.net.PlainDatagramSocketImpl.receive(PlainDatagramSocketImpl.java:136)
>     [junit]     - locked <0x1c517f78> (a java.net.PlainDatagramSocketImpl)
>     [junit]     at java.net.DatagramSocket.receive(DatagramSocket.java:712)
>     [junit]     - locked <0x1c59c280> (a java.net.DatagramPacket)
>     [junit]     - locked <0x1c517fb8> (a java.net.MulticastSocket)
>     [junit]     at org.apache.activemq.transport.discovery.multicast.MulticastDiscoveryAgent.run(MulticastDiscoveryAgent.java:239)
>     [junit]     at java.lang.Thread.run(Thread.java:613)
>     [junit] 
>     [junit] "Transport Status Dector org.apache.activemq.broker.TransportConnector@215748" daemon prio=9 tid=0x0052f1c0 nid=0x18c6600 waiting on condition [0xf151a000..0xf151aad0]
>     [junit]     at java.lang.Thread.sleep(Native Method)
>     [junit]     at org.apache.activemq.broker.TransportStatusDetector.run(TransportStatusDetector.java:98)
>     [junit]     at java.lang.Thread.run(Thread.java:613)
>     [junit] 
>     [junit] "MulticastDiscovery: tcp://bigmac-6.local:53747" daemon prio=5 tid=0x0052edf0 nid=0x18b9e00 runnable [0xf1499000..0xf1499ad0]
>     [junit]     at java.net.PlainDatagramSocketImpl.receive0(Native Method)
>     [junit]     at java.net.PlainDatagramSocketImpl.receive(PlainDatagramSocketImpl.java:136)
>     [junit]     - locked <0x1c51a138> (a java.net.PlainDatagramSocketImpl)
>     [junit]     at java.net.DatagramSocket.receive(DatagramSocket.java:712)
>     [junit]     - locked <0x1c51a178> (a java.net.DatagramPacket)
>     [junit]     - locked <0x1c51a198> (a java.net.MulticastSocket)
>     [junit]     at org.apache.activemq.transport.discovery.multicast.MulticastDiscoveryAgent.run(MulticastDiscoveryAgent.java:239)
>     [junit]     at java.lang.Thread.run(Thread.java:613)
>     [junit] 
>     [junit] "TcpTransportServer@tcp://bigmac-6.local:53747" daemon prio=9 tid=0x0052e9b0 nid=0x18b9a00 runnable [0xf1418000..0xf1418ad0]
>     [junit]     at java.net.PlainSocketImpl.socketAccept(Native Method)
>     [junit]     at java.net.PlainSocketImpl.accept(PlainSocketImpl.java:384)
>     [junit]     - locked <0x1c51a288> (a java.net.SocksSocketImpl)
>     [junit]     at java.net.ServerSocket.implAccept(ServerSocket.java:450)
>     [junit]     at java.net.ServerSocket.accept(ServerSocket.java:421)
>     [junit]     at org.apache.activemq.transport.tcp.TcpTransportServer.run(TcpTransportServer.java:96)
>     [junit]     at java.lang.Thread.run(Thread.java:613)
>     [junit] 
>     [junit] "ActiveMQ Scheduler" daemon prio=5 tid=0x0052dcf0 nid=0x184a600 in Object.wait() [0xf1397000..0xf1397ad0]
>     [junit]     at java.lang.Object.wait(Native Method)
>     [junit]     - waiting on <0x1c3d6210> (a java.lang.Object)
>     [junit]     at java.lang.Object.wait(Object.java:432)
>     [junit]     at edu.emory.mathcs.backport.java.util.concurrent.TimeUnit.timedWait(TimeUnit.java:294)
>     [junit]     at edu.emory.mathcs.backport.java.util.concurrent.DelayQueue.take(DelayQueue.java:156)
>     [junit]     - locked <0x1c3d6210> (a java.lang.Object)
>     [junit]     at edu.emory.mathcs.backport.java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:470)
>     [junit]     at edu.emory.mathcs.backport.java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:667)
>     [junit]     at java.lang.Thread.run(Thread.java:613)
>     [junit] 
>     [junit] "tcp:///127.0.0.1:53746" daemon prio=9 tid=0x0052bd60 nid=0x1907c00 runnable [0xf1214000..0xf1214ad0]
>     [junit]     at java.net.SocketInputStream.socketRead0(Native Method)
>     [junit]     at java.net.SocketInputStream.read(SocketInputStream.java:129)
>     [junit]     at org.apache.activemq.transport.tcp.TcpBufferedInputStream.fill(TcpBufferedInputStream.java:48)
>     [junit]     at org.apache.activemq.transport.tcp.TcpBufferedInputStream.read(TcpBufferedInputStream.java:55)
>     [junit]     at java.io.DataInputStream.readInt(DataInputStream.java:353)
>     [junit]     at org.apache.activemq.openwire.OpenWireFormat.unmarshal(OpenWireFormat.java:180)
>     [junit]     at org.apache.activemq.transport.tcp.TcpTransport.run(TcpTransport.java:135)
>     [junit]     at java.lang.Thread.run(Thread.java:613)
>     [junit] 
>     [junit] "tcp://localhost/127.0.0.1:53745" prio=5 tid=0x0052ba20 nid=0x1908000 in Object.wait() [0xf1193000..0xf1193ad0]
>     [junit]     at java.lang.Object.wait(Native Method)
>     [junit]     - waiting on <0x1c4f4728> (a edu.emory.mathcs.backport.java.util.concurrent.CountDownLatch)
>     [junit]     at java.lang.Object.wait(Object.java:474)
>     [junit]     at edu.emory.mathcs.backport.java.util.concurrent.CountDownLatch.await(CountDownLatch.java:173)
>     [junit]     - locked <0x1c4f4728> (a edu.emory.mathcs.backport.java.util.concurrent.CountDownLatch)
>     [junit]     at org.apache.activemq.network.DemandForwardingBridge.waitStarted(DemandForwardingBridge.java:481)
>     [junit]     at org.apache.activemq.network.DemandForwardingBridge.serviceRemoteCommand(DemandForwardingBridge.java:250)
>     [junit]     - locked <0x1c4f47b0> (a java.lang.Object)
>     [junit]     at org.apache.activemq.network.DemandForwardingBridge$2.onCommand(DemandForwardingBridge.java:121)
>     [junit]     at org.apache.activemq.transport.ResponseCorrelator.onCommand(ResponseCorrelator.java:82)
>     [junit]     at org.apache.activemq.transport.TransportFilter.onCommand(TransportFilter.java:68)
>     [junit]     at org.apache.activemq.transport.failover.FailoverTransport$1.onCommand(FailoverTransport.java:103)
>     [junit]     at org.apache.activemq.transport.WireFormatNegotiator.onCommand(WireFormatNegotiator.java:105)
>     [junit]     at org.apache.activemq.transport.TransportSupport.doConsume(TransportSupport.java:77)
>     [junit]     at org.apache.activemq.transport.tcp.TcpTransport.run(TcpTransport.java:136)
>     [junit]     at java.lang.Thread.run(Thread.java:613)
>     [junit] 
>     [junit] "ActiveMQ Default Thread Pool Thread" daemon prio=5 tid=0x0052afc0 nid=0x18e5600 in Object.wait() [0xf1112000..0xf1112ad0]
>     [junit]     at java.lang.Object.wait(Native Method)
>     [junit]     - waiting on <0x1c4a8840> (a java.lang.Object)
>     [junit]     at java.lang.Object.wait(Object.java:474)
>     [junit]     at edu.emory.mathcs.backport.java.util.concurrent.DelayQueue.take(DelayQueue.java:152)
>     [junit]     - locked <0x1c4a8840> (a java.lang.Object)
>     [junit]     at edu.emory.mathcs.backport.java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:470)
>     [junit]     at edu.emory.mathcs.backport.java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:667)
>     [junit]     at java.lang.Thread.run(Thread.java:613)
>     [junit] 
>     [junit] "Transport Status Dector org.apache.activemq.broker.TransportConnector@426f2d" daemon prio=9 tid=0x00529180 nid=0x18e5200 waiting on condition [0xf1091000..0xf1091ad0]
>     [junit]     at java.lang.Thread.sleep(Native Method)
>     [junit]     at org.apache.activemq.broker.TransportStatusDetector.run(TransportStatusDetector.java:98)
>     [junit]     at java.lang.Thread.run(Thread.java:613)
>     [junit] 
>     [junit] "MulticastDiscovery: null" daemon prio=5 tid=0x00528760 nid=0x18e5a00 runnable [0xf1010000..0xf1010ad0]
>     [junit]     at java.net.PlainDatagramSocketImpl.receive0(Native Method)
>     [junit]     at java.net.PlainDatagramSocketImpl.receive(PlainDatagramSocketImpl.java:136)
>     [junit]     - locked <0x1c3e7818> (a java.net.PlainDatagramSocketImpl)
>     [junit]     at java.net.DatagramSocket.receive(DatagramSocket.java:712)
>     [junit]     - locked <0x1c3e7858> (a java.net.DatagramPacket)
>     [junit]     - locked <0x1c3e7878> (a java.net.MulticastSocket)
>     [junit]     at org.apache.activemq.transport.discovery.multicast.MulticastDiscoveryAgent.run(MulticastDiscoveryAgent.java:239)
>     [junit]     at java.lang.Thread.run(Thread.java:613)
>     [junit] 
>     [junit] "Transport Status Dector org.apache.activemq.broker.TransportConnector@f0bca1" daemon prio=9 tid=0x00528420 nid=0x18e4e00 waiting on condition [0xf0f8f000..0xf0f8fad0]
>     [junit]     at java.lang.Thread.sleep(Native Method)
>     [junit]     at org.apache.activemq.broker.TransportStatusDetector.run(TransportStatusDetector.java:98)
>     [junit]     at java.lang.Thread.run(Thread.java:613)
>     [junit] 
>     [junit] "MulticastDiscovery: tcp://bigmac-6.local:53745" daemon prio=5 tid=0x00527c80 nid=0x18e4a00 runnable [0xf0f0e000..0xf0f0ead0]
>     [junit]     at java.net.PlainDatagramSocketImpl.receive0(Native Method)
>     [junit]     at java.net.PlainDatagramSocketImpl.receive(PlainDatagramSocketImpl.java:136)
>     [junit]     - locked <0x1c3e99f8> (a java.net.PlainDatagramSocketImpl)
>     [junit]     at java.net.DatagramSocket.receive(DatagramSocket.java:712)
>     [junit]     - locked <0x1c3e9a38> (a java.net.DatagramPacket)
>     [junit]     - locked <0x1c3e9a58> (a java.net.MulticastSocket)
>     [junit]     at org.apache.activemq.transport.discovery.multicast.MulticastDiscoveryAgent.run(MulticastDiscoveryAgent.java:239)
>     [junit]     at java.lang.Thread.run(Thread.java:613)
>     [junit] 
>     [junit] "TcpTransportServer@tcp://bigmac-6.local:53745" daemon prio=9 tid=0x00527800 nid=0x18e4600 runnable [0xf0e8d000..0xf0e8dad0]
>     [junit]     at java.net.PlainSocketImpl.socketAccept(Native Method)
>     [junit]     at java.net.PlainSocketImpl.accept(PlainSocketImpl.java:384)
>     [junit]     - locked <0x1c3dd958> (a java.net.SocksSocketImpl)
>     [junit]     at java.net.ServerSocket.implAccept(ServerSocket.java:450)
>     [junit]     at java.net.ServerSocket.accept(ServerSocket.java:421)
>     [junit]     at org.apache.activemq.transport.tcp.TcpTransportServer.run(TcpTransportServer.java:96)
>     [junit]     at java.lang.Thread.run(Thread.java:613)
>     [junit] 
>     [junit] "ActiveMQ Scheduler" daemon prio=5 tid=0x005268c0 nid=0x18e4200 in Object.wait() [0xf0e0c000..0xf0e0cad0]
>     [junit]     at java.lang.Object.wait(Native Method)
>     [junit]     - waiting on <0x1c3d6210> (a java.lang.Object)
>     [junit]     at java.lang.Object.wait(Object.java:432)
>     [junit]     at edu.emory.mathcs.backport.java.util.concurrent.TimeUnit.timedWait(TimeUnit.java:294)
>     [junit]     at edu.emory.mathcs.backport.java.util.concurrent.DelayQueue.take(DelayQueue.java:156)
>     [junit]     - locked <0x1c3d6210> (a java.lang.Object)
>     [junit]     at edu.emory.mathcs.backport.java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:470)
>     [junit]     at edu.emory.mathcs.backport.java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:667)
>     [junit]     at java.lang.Thread.run(Thread.java:613)
>     [junit] 
>     [junit] "derby.rawStoreDaemon" daemon prio=5 tid=0x00516e60 nid=0x184d000 in Object.wait() [0xf0d0a000..0xf0d0aad0]
>     [junit]     at java.lang.Object.wait(Native Method)
>     [junit]     - waiting on <0x1c2e5f50> (a org.apache.derby.impl.services.daemon.BasicDaemon)
>     [junit]     at org.apache.derby.impl.services.daemon.BasicDaemon.rest(Unknown Source)
>     [junit]     - locked <0x1c2e5f50> (a org.apache.derby.impl.services.daemon.BasicDaemon)
>     [junit]     at org.apache.derby.impl.services.daemon.BasicDaemon.run(Unknown Source)
>     [junit]     at java.lang.Thread.run(Thread.java:613)
>     [junit] 
>     [junit] "derby.antiGC" daemon prio=1 tid=0x00515d80 nid=0x18b5400 in Object.wait() [0xf0c89000..0xf0c89ad0]
>     [junit]     at java.lang.Object.wait(Native Method)
>     [junit]     - waiting on <0x1c2c60c8> (a org.apache.derby.impl.services.monitor.AntiGC)
>     [junit]     at java.lang.Object.wait(Object.java:474)
>     [junit]     at org.apache.derby.impl.services.monitor.AntiGC.run(Unknown Source)
>     [junit]     - locked <0x1c2c60c8> (a org.apache.derby.impl.services.monitor.AntiGC)
>     [junit]     at java.lang.Thread.run(Thread.java:613)
>     [junit] 
>     [junit] "Low Memory Detector" daemon prio=5 tid=0x0050b0a0 nid=0x1813c00 runnable [0x00000000..0x00000000]
>     [junit] 
>     [junit] "CompilerThread0" daemon prio=10 tid=0x0050a6e0 nid=0x1813800 waiting on condition [0x00000000..0xf0b06378]
>     [junit] 
>     [junit] "Signal Dispatcher" daemon prio=10 tid=0x0050a220 nid=0x1812a00 waiting on condition [0x00000000..0x00000000]
>     [junit] 
>     [junit] "Finalizer" daemon prio=8 tid=0x005099b0 nid=0x1811800 in Object.wait() [0xf0a04000..0xf0a04ad0]
>     [junit]     at java.lang.Object.wait(Native Method)
>     [junit]     - waiting on <0x1c1fbc60> (a java.lang.ref.ReferenceQueue$Lock)
>     [junit]     at java.lang.ref.ReferenceQueue.remove(ReferenceQueue.java:116)
>     [junit]     - locked <0x1c1fbc60> (a java.lang.ref.ReferenceQueue$Lock)
>     [junit]     at java.lang.ref.ReferenceQueue.remove(ReferenceQueue.java:132)
>     [junit]     at java.lang.ref.Finalizer$FinalizerThread.run(Finalizer.java:159)
>     [junit] 
>     [junit] "Reference Handler" daemon prio=10 tid=0x005095e0 nid=0x1810800 in Object.wait() [0xf0983000..0xf0983ad0]
>     [junit]     at java.lang.Object.wait(Native Method)
>     [junit]     - waiting on <0x1c1fbce0> (a java.lang.ref.Reference$Lock)
>     [junit]     at java.lang.Object.wait(Object.java:474)
>     [junit]     at java.lang.ref.Reference$ReferenceHandler.run(Reference.java:116)
>     [junit]     - locked <0x1c1fbce0> (a java.lang.ref.Reference$Lock)
>     [junit] 
>     [junit] "main" prio=5 tid=0x00501ad0 nid=0x1805400 in Object.wait() [0xf07ff000..0xf08002e0]
>     [junit]     at java.lang.Object.wait(Native Method)
>     [junit]     - waiting on <0x1c818088> (a org.apache.activemq.thread.SimpleTaskRunner$1)
>     [junit]     at java.lang.Object.wait(Object.java:474)
>     [junit]     at org.apache.activemq.thread.SimpleTaskRunner.shutdown(SimpleTaskRunner.java:88)
>     [junit]     - locked <0x1c818088> (a org.apache.activemq.thread.SimpleTaskRunner$1)
>     [junit]     at org.apache.activemq.ActiveMQSessionExecutor.stop(ActiveMQSessionExecutor.java:110)
>     [junit]     at org.apache.activemq.ActiveMQSession.stop(ActiveMQSession.java:1431)
>     [junit]     at org.apache.activemq.ActiveMQConnection.stop(ActiveMQConnection.java:464)
>     [junit]     at org.apache.activemq.ActiveMQConnection.close(ActiveMQConnection.java:516)
>     [junit]     at org.apache.activemq.transport.TopicClusterTest.tearDown(TopicClusterTest.java:98)
>     [junit]     at junit.framework.TestCase.runBare(TestCase.java:130)
>     [junit]     at junit.framework.TestResult$1.protect(TestResult.java:106)
>     [junit]     at junit.framework.TestResult.runProtected(TestResult.java:124)
>     [junit]     at junit.framework.TestResult.run(TestResult.java:109)
>     [junit]     at junit.framework.TestCase.run(TestCase.java:118)
>     [junit]     at junit.framework.TestSuite.runTest(TestSuite.java:208)
>     [junit]     at junit.framework.TestSuite.run(TestSuite.java:203)
>     [junit]     at org.apache.tools.ant.taskdefs.optional.junit.JUnitTestRunner.run(JUnitTestRunner.java:325)
>     [junit]     at org.apache.tools.ant.taskdefs.optional.junit.JUnitTestRunner.main(JUnitTestRunner.java:536)
>     [junit] 
>     [junit] "VM Thread" prio=10 tid=0x00508e60 nid=0x1803c00 runnable 
>     [junit] 
>     [junit] "VM Periodic Task Thread" prio=10 tid=0x0050c760 nid=0x1814000 waiting on condition 
>     [junit] 
>     [junit] "Exception Catcher Thread" prio=10 tid=0x00501cd0 nid=0x1806a00 runnable 
>     [junit] 
>     [junit] Found one Java-level deadlock:
>     [junit] =============================
>     [junit] "session Task":
>     [junit]   waiting to lock monitor 0x01810e68 (object 0x1c926760, a java.util.LinkedList),
>     [junit]   which is held by "tcp://localhost/127.0.0.1:53745"
>     [junit] "tcp://localhost/127.0.0.1:53745":
>     [junit]   waiting to lock monitor 0x01810e8c (object 0x1c8c9340, a org.apache.activemq.broker.region.QueueSubscription),
>     [junit]   which is held by "session Task"
>     [junit] 
>     [junit] Java stack information for the threads listed above:
>     [junit] ===================================================
>     [junit] "session Task":
>     [junit]     at org.apache.activemq.broker.region.Queue.dropEvent(Queue.java:263)
>     [junit]     - waiting to lock <0x1c926760> (a java.util.LinkedList)
>     [junit]     at org.apache.activemq.broker.region.QueueSubscription.acknowledge(QueueSubscription.java:55)
>     [junit]     at org.apache.activemq.broker.region.PrefetchSubscription.acknowledge(PrefetchSubscription.java:133)
>     [junit]     - locked <0x1c8c9340> (a org.apache.activemq.broker.region.QueueSubscription)
>     [junit]     at org.apache.activemq.broker.region.AbstractRegion.acknowledge(AbstractRegion.java:203)
>     [junit]     at org.apache.activemq.broker.region.RegionBroker.acknowledge(RegionBroker.java:329)
>     [junit]     at org.apache.activemq.broker.TransactionBroker.acknowledge(TransactionBroker.java:176)
>     [junit]     at org.apache.activemq.broker.BrokerFilter.acknowledge(BrokerFilter.java:59)
>     [junit]     at org.apache.activemq.broker.BrokerFilter.acknowledge(BrokerFilter.java:59)
>     [junit]     at org.apache.activemq.broker.MutableBrokerFilter.acknowledge(MutableBrokerFilter.java:71)
>     [junit]     at org.apache.activemq.broker.AbstractConnection.processMessageAck(AbstractConnection.java:342)
>     [junit]     at org.apache.activemq.command.MessageAck.visit(MessageAck.java:178)
>     [junit]     at org.apache.activemq.broker.AbstractConnection.service(AbstractConnection.java:190)
>     [junit]     at org.apache.activemq.broker.TransportConnection$1.onCommand(TransportConnection.java:60)
>     [junit]     at org.apache.activemq.transport.ResponseCorrelator.onCommand(ResponseCorrelator.java:82)
>     [junit]     at org.apache.activemq.transport.TransportFilter.onCommand(TransportFilter.java:68)
>     [junit]     at org.apache.activemq.transport.vm.VMTransport.oneway(VMTransport.java:75)
>     [junit]     at org.apache.activemq.transport.MutexTransport.oneway(MutexTransport.java:44)
>     [junit]     - locked <0x1c8180d8> (a java.lang.Object)
>     [junit]     at org.apache.activemq.transport.ResponseCorrelator.oneway(ResponseCorrelator.java:54)
>     [junit]     at org.apache.activemq.ActiveMQConnection.asyncSendPacket(ActiveMQConnection.java:1041)
>     [junit]     at org.apache.activemq.ActiveMQSession.asyncSendPacket(ActiveMQSession.java:1617)
>     [junit]     at org.apache.activemq.ActiveMQMessageConsumer.afterMessageIsConsumed(ActiveMQMessageConsumer.java:554)
>     [junit]     at org.apache.activemq.ActiveMQMessageConsumer.dispatch(ActiveMQMessageConsumer.java:716)
>     [junit]     at org.apache.activemq.ActiveMQSessionExecutor.dispatch(ActiveMQSessionExecutor.java:93)
>     [junit]     at org.apache.activemq.ActiveMQSessionExecutor.iterate(ActiveMQSessionExecutor.java:146)
>     [junit]     at org.apache.activemq.thread.SimpleTaskRunner.runTask(SimpleTaskRunner.java:110)
>     [junit]     at org.apache.activemq.thread.SimpleTaskRunner.access$100(SimpleTaskRunner.java:25)
>     [junit]     at org.apache.activemq.thread.SimpleTaskRunner$1.run(SimpleTaskRunner.java:43)
>     [junit]     at edu.emory.mathcs.backport.java.util.concurrent.ThreadPoolExecutor$Worker.runTask(ThreadPoolExecutor.java:643)
>     [junit]     at edu.emory.mathcs.backport.java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:668)
>     [junit]     at java.lang.Thread.run(Thread.java:613)
>     [junit] "tcp://localhost/127.0.0.1:53745":
>     [junit]     at org.apache.activemq.broker.region.PrefetchSubscription.add(PrefetchSubscription.java:58)
>     [junit]     - waiting to lock <0x1c8c9340> (a org.apache.activemq.broker.region.QueueSubscription)
>     [junit]     at org.apache.activemq.broker.region.QueueSubscription.add(QueueSubscription.java:38)
>     [junit]     at org.apache.activemq.broker.region.policy.RoundRobinDispatchPolicy.dispatch(RoundRobinDispatchPolicy.java:53)
>     [junit]     - locked <0x1c926f28> (a edu.emory.mathcs.backport.java.util.concurrent.CopyOnWriteArrayList)
>     [junit]     at org.apache.activemq.broker.region.Queue.removeSubscription(Queue.java:210)
>     [junit]     - locked <0x1c926760> (a java.util.LinkedList)
>     [junit]     at org.apache.activemq.broker.region.AbstractRegion.removeConsumer(AbstractRegion.java:179)
>     [junit]     at org.apache.activemq.broker.region.RegionBroker.removeConsumer(RegionBroker.java:280)
>     [junit]     at org.apache.activemq.broker.BrokerFilter.removeConsumer(BrokerFilter.java:95)
>     [junit]     at org.apache.activemq.advisory.AdvisoryBroker.removeConsumer(AdvisoryBroker.java:164)
>     [junit]     at org.apache.activemq.broker.BrokerFilter.removeConsumer(BrokerFilter.java:95)
>     [junit]     at org.apache.activemq.broker.MutableBrokerFilter.removeConsumer(MutableBrokerFilter.java:107)
>     [junit]     at org.apache.activemq.broker.AbstractConnection.processRemoveConsumer(AbstractConnection.java:431)
>     [junit]     at org.apache.activemq.command.RemoveInfo.visit(RemoveInfo.java:63)
>     [junit]     at org.apache.activemq.broker.AbstractConnection.service(AbstractConnection.java:190)
>     [junit]     at org.apache.activemq.broker.TransportConnection$1.onCommand(TransportConnection.java:60)
>     [junit]     at org.apache.activemq.transport.ResponseCorrelator.onCommand(ResponseCorrelator.java:82)
>     [junit]     at org.apache.activemq.transport.TransportFilter.onCommand(TransportFilter.java:68)
>     [junit]     at org.apache.activemq.transport.vm.VMTransport.oneway(VMTransport.java:75)
>     [junit]     at org.apache.activemq.transport.MutexTransport.oneway(MutexTransport.java:44)
>     [junit]     - locked <0x1c80aac8> (a java.lang.Object)
>     [junit]     at org.apache.activemq.transport.ResponseCorrelator.oneway(ResponseCorrelator.java:54)
>     [junit]     at org.apache.activemq.network.DemandForwardingBridge.serviceRemoteConsumerAdvisory(DemandForwardingBridge.java:331)
>     [junit]     at org.apache.activemq.network.DemandForwardingBridge.serviceRemoteCommand(DemandForwardingBridge.java:235)
>     [junit]     at org.apache.activemq.network.DemandForwardingBridge$2.onCommand(DemandForwardingBridge.java:121)
>     [junit]     at org.apache.activemq.transport.ResponseCorrelator.onCommand(ResponseCorrelator.java:82)
>     [junit]     at org.apache.activemq.transport.TransportFilter.onCommand(TransportFilter.java:68)
>     [junit]     at org.apache.activemq.transport.failover.FailoverTransport$1.onCommand(FailoverTransport.java:103)
>     [junit]     at org.apache.activemq.transport.WireFormatNegotiator.onCommand(WireFormatNegotiator.java:105)
>     [junit]     at org.apache.activemq.transport.TransportSupport.doConsume(TransportSupport.java:77)
>     [junit]     at org.apache.activemq.transport.tcp.TcpTransport.run(TcpTransport.java:136)
>     [junit]     at java.lang.Thread.run(Thread.java:613)
>     [junit] 
>     [junit] Found 1 deadlock.                                                                                        

-- 
This message is automatically generated by JIRA.
-
If you think it was sent incorrectly contact one of the administrators: https://issues.apache.org/activemq/secure/Administrators.jspa
-
For more information on JIRA, see: http://www.atlassian.com/software/jira