ARTEMIS-127 Fix some concurrency idioms for ActimeMQ Tests
This commit is contained in:
parent
64ecb9565d
commit
ae6a2b87ea
|
@ -36,7 +36,7 @@ public class JmsCreateConsumerInOnMessageTest extends TestSupport implements Mes
|
||||||
private MessageConsumer testConsumer;
|
private MessageConsumer testConsumer;
|
||||||
private MessageProducer producer;
|
private MessageProducer producer;
|
||||||
private Topic topic;
|
private Topic topic;
|
||||||
private Object lock = new Object();
|
private final Object lock = new Object();
|
||||||
|
|
||||||
/*
|
/*
|
||||||
* @see junit.framework.TestCase#setUp()
|
* @see junit.framework.TestCase#setUp()
|
||||||
|
@ -71,8 +71,8 @@ public class JmsCreateConsumerInOnMessageTest extends TestSupport implements Mes
|
||||||
public void testCreateConsumer() throws Exception {
|
public void testCreateConsumer() throws Exception {
|
||||||
Message msg = super.createMessage();
|
Message msg = super.createMessage();
|
||||||
producer.send(msg);
|
producer.send(msg);
|
||||||
if (testConsumer == null) {
|
synchronized (lock) {
|
||||||
synchronized (lock) {
|
while(testConsumer == null) {
|
||||||
lock.wait(3000);
|
lock.wait(3000);
|
||||||
}
|
}
|
||||||
}
|
}
|
||||||
|
|
|
@ -83,8 +83,6 @@ public class JmsMultipleClientsTestSupport {
|
||||||
protected List<Connection> connections = Collections.synchronizedList(new ArrayList<Connection>());
|
protected List<Connection> connections = Collections.synchronizedList(new ArrayList<Connection>());
|
||||||
protected MessageIdList allMessagesList = new MessageIdList();
|
protected MessageIdList allMessagesList = new MessageIdList();
|
||||||
|
|
||||||
private AtomicInteger producerLock;
|
|
||||||
|
|
||||||
protected void startProducers(Destination dest, int msgCount) throws Exception {
|
protected void startProducers(Destination dest, int msgCount) throws Exception {
|
||||||
startProducers(createConnectionFactory(), dest, msgCount);
|
startProducers(createConnectionFactory(), dest, msgCount);
|
||||||
}
|
}
|
||||||
|
@ -92,7 +90,7 @@ public class JmsMultipleClientsTestSupport {
|
||||||
protected void startProducers(final ConnectionFactory factory, final Destination dest, final int msgCount) throws Exception {
|
protected void startProducers(final ConnectionFactory factory, final Destination dest, final int msgCount) throws Exception {
|
||||||
// Use concurrent send
|
// Use concurrent send
|
||||||
if (useConcurrentSend) {
|
if (useConcurrentSend) {
|
||||||
producerLock = new AtomicInteger(producerCount);
|
final AtomicInteger producerLock = new AtomicInteger(producerCount);
|
||||||
|
|
||||||
for (int i = 0; i < producerCount; i++) {
|
for (int i = 0; i < producerCount; i++) {
|
||||||
Thread t = new Thread(new Runnable() {
|
Thread t = new Thread(new Runnable() {
|
||||||
|
|
|
@ -61,7 +61,7 @@ public class LargeMessageTestSupport extends ClientTestSupport implements Messag
|
||||||
protected int deliveryMode = DeliveryMode.PERSISTENT;
|
protected int deliveryMode = DeliveryMode.PERSISTENT;
|
||||||
protected IdGenerator idGen = new IdGenerator();
|
protected IdGenerator idGen = new IdGenerator();
|
||||||
protected boolean validMessageConsumption = true;
|
protected boolean validMessageConsumption = true;
|
||||||
protected AtomicInteger messageCount = new AtomicInteger(0);
|
protected final AtomicInteger messageCount = new AtomicInteger(0);
|
||||||
|
|
||||||
protected int prefetchValue = 10000000;
|
protected int prefetchValue = 10000000;
|
||||||
|
|
||||||
|
@ -182,9 +182,9 @@ public class LargeMessageTestSupport extends ClientTestSupport implements Messag
|
||||||
producer.send(msg);
|
producer.send(msg);
|
||||||
}
|
}
|
||||||
long now = System.currentTimeMillis();
|
long now = System.currentTimeMillis();
|
||||||
while (now + 60000 > System.currentTimeMillis() && messageCount.get() < MESSAGE_COUNT) {
|
synchronized (messageCount) {
|
||||||
LOG.info("message count = " + messageCount);
|
while (now + 60000 > System.currentTimeMillis() && messageCount.get() < MESSAGE_COUNT) {
|
||||||
synchronized (messageCount) {
|
LOG.info("message count = " + messageCount);
|
||||||
messageCount.wait(1000);
|
messageCount.wait(1000);
|
||||||
}
|
}
|
||||||
}
|
}
|
||||||
|
|
|
@ -154,7 +154,7 @@ public class OnePrefetchAsyncConsumerTest extends EmbeddedBrokerTestSupport {
|
||||||
}
|
}
|
||||||
|
|
||||||
private class TestServerSession implements ServerSession {
|
private class TestServerSession implements ServerSession {
|
||||||
TestServerSessionPool pool;
|
final TestServerSessionPool pool;
|
||||||
Session session;
|
Session session;
|
||||||
|
|
||||||
public TestServerSession(TestServerSessionPool pool) throws JMSException {
|
public TestServerSession(TestServerSessionPool pool) throws JMSException {
|
||||||
|
|
|
@ -54,7 +54,7 @@ public class QueueResendDuringShutdownTest {
|
||||||
private Connection producerConnection;
|
private Connection producerConnection;
|
||||||
private Queue queue;
|
private Queue queue;
|
||||||
|
|
||||||
private Object messageReceiveSync = new Object();
|
private final Object messageReceiveSync = new Object();
|
||||||
private int receiveCount;
|
private int receiveCount;
|
||||||
|
|
||||||
@Before
|
@Before
|
||||||
|
@ -239,7 +239,7 @@ public class QueueResendDuringShutdownTest {
|
||||||
protected void waitForMessage (long delayMs) {
|
protected void waitForMessage (long delayMs) {
|
||||||
try {
|
try {
|
||||||
synchronized ( this.messageReceiveSync ) {
|
synchronized ( this.messageReceiveSync ) {
|
||||||
if ( this.receiveCount == 0 ) {
|
while ( this.receiveCount == 0 ) {
|
||||||
this.messageReceiveSync.wait(delayMs);
|
this.messageReceiveSync.wait(delayMs);
|
||||||
}
|
}
|
||||||
}
|
}
|
||||||
|
|
|
@ -563,7 +563,7 @@ public class AMQ2149Test {
|
||||||
}
|
}
|
||||||
|
|
||||||
class TeardownTask implements Callable<Boolean> {
|
class TeardownTask implements Callable<Boolean> {
|
||||||
private Object brokerLock;
|
private final Object brokerLock;
|
||||||
private BrokerService broker;
|
private BrokerService broker;
|
||||||
|
|
||||||
public TeardownTask(Object brokerLock, BrokerService broker) {
|
public TeardownTask(Object brokerLock, BrokerService broker) {
|
||||||
|
|
|
@ -49,7 +49,7 @@ public class AMQ4607Test extends JmsMultipleBrokersTestSupport implements Uncaug
|
||||||
|
|
||||||
public boolean duplex = true;
|
public boolean duplex = true;
|
||||||
protected Map<String, MessageConsumer> consumerMap;
|
protected Map<String, MessageConsumer> consumerMap;
|
||||||
Map<Thread, Throwable> unhandeledExceptions = new HashMap<Thread, Throwable>();
|
final Map<Thread, Throwable> unhandeledExceptions = new HashMap<Thread, Throwable>();
|
||||||
|
|
||||||
private void assertNoUnhandeledExceptions() {
|
private void assertNoUnhandeledExceptions() {
|
||||||
for( Entry<Thread, Throwable> e: unhandeledExceptions.entrySet()) {
|
for( Entry<Thread, Throwable> e: unhandeledExceptions.entrySet()) {
|
||||||
|
|
|
@ -25,6 +25,9 @@ import org.apache.activemq.ActiveMQConnectionFactory;
|
||||||
import org.apache.activemq.EmbeddedBrokerTestSupport;
|
import org.apache.activemq.EmbeddedBrokerTestSupport;
|
||||||
import org.apache.activemq.command.ActiveMQQueue;
|
import org.apache.activemq.command.ActiveMQQueue;
|
||||||
|
|
||||||
|
import java.util.concurrent.CountDownLatch;
|
||||||
|
import java.util.concurrent.TimeUnit;
|
||||||
|
|
||||||
public class CraigsBugTest extends EmbeddedBrokerTestSupport {
|
public class CraigsBugTest extends EmbeddedBrokerTestSupport {
|
||||||
|
|
||||||
private String connectionUri;
|
private String connectionUri;
|
||||||
|
@ -49,9 +52,7 @@ public class CraigsBugTest extends EmbeddedBrokerTestSupport {
|
||||||
conn.start();
|
conn.start();
|
||||||
|
|
||||||
try {
|
try {
|
||||||
synchronized (this) {
|
new CountDownLatch(1).await(3, TimeUnit.SECONDS);
|
||||||
wait(3000);
|
|
||||||
}
|
|
||||||
} catch (InterruptedException e) {
|
} catch (InterruptedException e) {
|
||||||
e.printStackTrace();
|
e.printStackTrace();
|
||||||
}
|
}
|
||||||
|
|
|
@ -25,6 +25,7 @@ import org.apache.activemq.transport.discovery.simple.SimpleDiscoveryAgent;
|
||||||
import javax.jms.*;
|
import javax.jms.*;
|
||||||
import java.io.File;
|
import java.io.File;
|
||||||
import java.net.URISyntaxException;
|
import java.net.URISyntaxException;
|
||||||
|
import java.util.concurrent.CountDownLatch;
|
||||||
|
|
||||||
public class TryJmsClient
|
public class TryJmsClient
|
||||||
{
|
{
|
||||||
|
@ -59,9 +60,7 @@ public class TryJmsClient
|
||||||
|
|
||||||
startMessageSend();
|
startMessageSend();
|
||||||
|
|
||||||
synchronized(this) {
|
new CountDownLatch(1).await();
|
||||||
this.wait();
|
|
||||||
}
|
|
||||||
}
|
}
|
||||||
|
|
||||||
private void startUsageMonitor(final BrokerService brokerService) {
|
private void startUsageMonitor(final BrokerService brokerService) {
|
||||||
|
|
|
@ -25,6 +25,7 @@ import org.apache.activemq.transport.discovery.simple.SimpleDiscoveryAgent;
|
||||||
import javax.jms.*;
|
import javax.jms.*;
|
||||||
import java.io.File;
|
import java.io.File;
|
||||||
import java.net.URISyntaxException;
|
import java.net.URISyntaxException;
|
||||||
|
import java.util.concurrent.CountDownLatch;
|
||||||
|
|
||||||
public class TryJmsManager {
|
public class TryJmsManager {
|
||||||
|
|
||||||
|
@ -59,9 +60,7 @@ public class TryJmsManager {
|
||||||
|
|
||||||
startMessageConsumer();
|
startMessageConsumer();
|
||||||
|
|
||||||
synchronized(this) {
|
new CountDownLatch(1).await();
|
||||||
this.wait();
|
|
||||||
}
|
|
||||||
}
|
}
|
||||||
|
|
||||||
private void startUsageMonitor(final BrokerService brokerService) {
|
private void startUsageMonitor(final BrokerService brokerService) {
|
||||||
|
|
|
@ -73,14 +73,19 @@ public class ConsumerBean extends Assert implements MessageListener {
|
||||||
|
|
||||||
long start = System.currentTimeMillis();
|
long start = System.currentTimeMillis();
|
||||||
|
|
||||||
try {
|
synchronized(messages)
|
||||||
if (hasReceivedMessage()) {
|
{
|
||||||
synchronized (messages) {
|
try
|
||||||
|
{
|
||||||
|
while (hasReceivedMessage())
|
||||||
|
{
|
||||||
messages.wait(4000);
|
messages.wait(4000);
|
||||||
}
|
}
|
||||||
}
|
}
|
||||||
} catch (InterruptedException e) {
|
catch (InterruptedException e)
|
||||||
LOG.info("Caught: " + e);
|
{
|
||||||
|
LOG.info("Caught: " + e);
|
||||||
|
}
|
||||||
}
|
}
|
||||||
long end = System.currentTimeMillis() - start;
|
long end = System.currentTimeMillis() - start;
|
||||||
|
|
||||||
|
@ -101,18 +106,18 @@ public class ConsumerBean extends Assert implements MessageListener {
|
||||||
LOG.info("Waiting for (" + maxRemainingMessageCount + ") message(s) to arrive");
|
LOG.info("Waiting for (" + maxRemainingMessageCount + ") message(s) to arrive");
|
||||||
long start = System.currentTimeMillis();
|
long start = System.currentTimeMillis();
|
||||||
long endTime = start + maxWaitTime;
|
long endTime = start + maxWaitTime;
|
||||||
while (maxRemainingMessageCount > 0) {
|
synchronized (messages) {
|
||||||
try {
|
while (maxRemainingMessageCount > 0) {
|
||||||
synchronized (messages) {
|
try {
|
||||||
messages.wait(1000);
|
messages.wait(1000);
|
||||||
|
if (hasReceivedMessages(messageCount) || System.currentTimeMillis() > endTime) {
|
||||||
|
break;
|
||||||
|
}
|
||||||
|
} catch (InterruptedException e) {
|
||||||
|
LOG.info("Caught: " + e);
|
||||||
}
|
}
|
||||||
if (hasReceivedMessages(messageCount) || System.currentTimeMillis() > endTime) {
|
maxRemainingMessageCount = Math.max(0, messageCount - messages.size());
|
||||||
break;
|
|
||||||
}
|
|
||||||
} catch (InterruptedException e) {
|
|
||||||
LOG.info("Caught: " + e);
|
|
||||||
}
|
}
|
||||||
maxRemainingMessageCount = Math.max(0, messageCount - messages.size());
|
|
||||||
}
|
}
|
||||||
long end = System.currentTimeMillis() - start;
|
long end = System.currentTimeMillis() - start;
|
||||||
LOG.info("End of wait for " + end + " millis");
|
LOG.info("End of wait for " + end + " millis");
|
||||||
|
|
|
@ -43,13 +43,13 @@ public class SpringConsumer extends ConsumerBean implements MessageListener {
|
||||||
|
|
||||||
try {
|
try {
|
||||||
ConnectionFactory factory = template.getConnectionFactory();
|
ConnectionFactory factory = template.getConnectionFactory();
|
||||||
connection = factory.createConnection();
|
final Connection c = connection = factory.createConnection();
|
||||||
|
|
||||||
// we might be a reusable connection in spring
|
// we might be a reusable connection in spring
|
||||||
// so lets only set the client ID once if its not set
|
// so lets only set the client ID once if its not set
|
||||||
synchronized (connection) {
|
synchronized (c) {
|
||||||
if (connection.getClientID() == null) {
|
if (c.getClientID() == null) {
|
||||||
connection.setClientID(myId);
|
c.setClientID(myId);
|
||||||
}
|
}
|
||||||
}
|
}
|
||||||
|
|
||||||
|
|
|
@ -617,7 +617,7 @@ public class PListTest {
|
||||||
}
|
}
|
||||||
}
|
}
|
||||||
|
|
||||||
Map<PList, Object> locks = new HashMap<PList, Object>();
|
final Map<PList, Object> locks = new HashMap<PList, Object>();
|
||||||
|
|
||||||
private Object plistLocks(PList plist) {
|
private Object plistLocks(PList plist) {
|
||||||
Object lock = null;
|
Object lock = null;
|
||||||
|
|
|
@ -250,7 +250,7 @@ public class JMSInputStreamTest extends JmsTestSupport {
|
||||||
}
|
}
|
||||||
out.flush();
|
out.flush();
|
||||||
synchronized (complete) {
|
synchronized (complete) {
|
||||||
if (!complete.get()) {
|
while (!complete.get()) {
|
||||||
complete.wait(30000);
|
complete.wait(30000);
|
||||||
}
|
}
|
||||||
}
|
}
|
||||||
|
|
|
@ -55,7 +55,7 @@ public class TopicClusterTest extends TestCase implements MessageListener {
|
||||||
|
|
||||||
protected Destination destination;
|
protected Destination destination;
|
||||||
protected boolean topic = true;
|
protected boolean topic = true;
|
||||||
protected AtomicInteger receivedMessageCount = new AtomicInteger(0);
|
protected final AtomicInteger receivedMessageCount = new AtomicInteger(0);
|
||||||
protected int deliveryMode = DeliveryMode.NON_PERSISTENT;
|
protected int deliveryMode = DeliveryMode.NON_PERSISTENT;
|
||||||
protected MessageProducer[] producers;
|
protected MessageProducer[] producers;
|
||||||
protected Connection[] connections;
|
protected Connection[] connections;
|
||||||
|
@ -166,7 +166,7 @@ public class TopicClusterTest extends TestCase implements MessageListener {
|
||||||
}
|
}
|
||||||
}
|
}
|
||||||
synchronized (receivedMessageCount) {
|
synchronized (receivedMessageCount) {
|
||||||
if (receivedMessageCount.get() < expectedReceiveCount()) {
|
while (receivedMessageCount.get() < expectedReceiveCount()) {
|
||||||
receivedMessageCount.wait(20000);
|
receivedMessageCount.wait(20000);
|
||||||
}
|
}
|
||||||
}
|
}
|
||||||
|
|
|
@ -21,6 +21,7 @@ import java.net.URI;
|
||||||
import java.util.ArrayList;
|
import java.util.ArrayList;
|
||||||
import java.util.Collection;
|
import java.util.Collection;
|
||||||
import java.util.Set;
|
import java.util.Set;
|
||||||
|
import java.util.concurrent.CountDownLatch;
|
||||||
import java.util.concurrent.atomic.AtomicBoolean;
|
import java.util.concurrent.atomic.AtomicBoolean;
|
||||||
|
|
||||||
import javax.jms.Connection;
|
import javax.jms.Connection;
|
||||||
|
@ -73,14 +74,12 @@ public class AMQ1925Test extends TestCase implements ExceptionListener {
|
||||||
|
|
||||||
// The runnable is likely to interrupt during the session#commit, since
|
// The runnable is likely to interrupt during the session#commit, since
|
||||||
// this takes the longest
|
// this takes the longest
|
||||||
final Object starter = new Object();
|
final CountDownLatch starter = new CountDownLatch(1);
|
||||||
final AtomicBoolean restarted = new AtomicBoolean();
|
final AtomicBoolean restarted = new AtomicBoolean();
|
||||||
new Thread(new Runnable() {
|
new Thread(new Runnable() {
|
||||||
public void run() {
|
public void run() {
|
||||||
try {
|
try {
|
||||||
synchronized (starter) {
|
starter.await();
|
||||||
starter.wait();
|
|
||||||
}
|
|
||||||
|
|
||||||
// Simulate broker failure & restart
|
// Simulate broker failure & restart
|
||||||
bs.stop();
|
bs.stop();
|
||||||
|
@ -97,9 +96,6 @@ public class AMQ1925Test extends TestCase implements ExceptionListener {
|
||||||
}
|
}
|
||||||
}).start();
|
}).start();
|
||||||
|
|
||||||
synchronized (starter) {
|
|
||||||
starter.notifyAll();
|
|
||||||
}
|
|
||||||
for (int i = 0; i < MESSAGE_COUNT; i++) {
|
for (int i = 0; i < MESSAGE_COUNT; i++) {
|
||||||
Message message = consumer.receive(500);
|
Message message = consumer.receive(500);
|
||||||
assertNotNull("No Message " + i + " found", message);
|
assertNotNull("No Message " + i + " found", message);
|
||||||
|
@ -108,9 +104,7 @@ public class AMQ1925Test extends TestCase implements ExceptionListener {
|
||||||
assertFalse("Timing problem, restarted too soon", restarted
|
assertFalse("Timing problem, restarted too soon", restarted
|
||||||
.get());
|
.get());
|
||||||
if (i == 10) {
|
if (i == 10) {
|
||||||
synchronized (starter) {
|
starter.countDown();
|
||||||
starter.notifyAll();
|
|
||||||
}
|
|
||||||
}
|
}
|
||||||
if (i > MESSAGE_COUNT - 100) {
|
if (i > MESSAGE_COUNT - 100) {
|
||||||
assertTrue("Timing problem, restarted too late", restarted
|
assertTrue("Timing problem, restarted too late", restarted
|
||||||
|
@ -143,14 +137,12 @@ public class AMQ1925Test extends TestCase implements ExceptionListener {
|
||||||
|
|
||||||
// The runnable is likely to interrupt during the session#commit, since
|
// The runnable is likely to interrupt during the session#commit, since
|
||||||
// this takes the longest
|
// this takes the longest
|
||||||
final Object starter = new Object();
|
final CountDownLatch starter = new CountDownLatch(1);
|
||||||
final AtomicBoolean restarted = new AtomicBoolean();
|
final AtomicBoolean restarted = new AtomicBoolean();
|
||||||
new Thread(new Runnable() {
|
new Thread(new Runnable() {
|
||||||
public void run() {
|
public void run() {
|
||||||
try {
|
try {
|
||||||
synchronized (starter) {
|
starter.await();
|
||||||
starter.wait();
|
|
||||||
}
|
|
||||||
|
|
||||||
// Simulate broker failure & restart
|
// Simulate broker failure & restart
|
||||||
bs.stop();
|
bs.stop();
|
||||||
|
@ -167,9 +159,6 @@ public class AMQ1925Test extends TestCase implements ExceptionListener {
|
||||||
}
|
}
|
||||||
}).start();
|
}).start();
|
||||||
|
|
||||||
synchronized (starter) {
|
|
||||||
starter.notifyAll();
|
|
||||||
}
|
|
||||||
Collection<Integer> results = new ArrayList<Integer>(MESSAGE_COUNT);
|
Collection<Integer> results = new ArrayList<Integer>(MESSAGE_COUNT);
|
||||||
for (int i = 0; i < MESSAGE_COUNT; i++) {
|
for (int i = 0; i < MESSAGE_COUNT; i++) {
|
||||||
Message message1 = consumer1.receive(20);
|
Message message1 = consumer1.receive(20);
|
||||||
|
@ -191,9 +180,7 @@ public class AMQ1925Test extends TestCase implements ExceptionListener {
|
||||||
assertFalse("Timing problem, restarted too soon", restarted
|
assertFalse("Timing problem, restarted too soon", restarted
|
||||||
.get());
|
.get());
|
||||||
if (i == 10) {
|
if (i == 10) {
|
||||||
synchronized (starter) {
|
starter.countDown();
|
||||||
starter.notifyAll();
|
|
||||||
}
|
|
||||||
}
|
}
|
||||||
if (i > MESSAGE_COUNT - 50) {
|
if (i > MESSAGE_COUNT - 50) {
|
||||||
assertTrue("Timing problem, restarted too late", restarted
|
assertTrue("Timing problem, restarted too late", restarted
|
||||||
|
|
|
@ -46,7 +46,7 @@ public abstract class UdpTestSupport extends TestCase implements TransportListen
|
||||||
protected Transport producer;
|
protected Transport producer;
|
||||||
protected Transport consumer;
|
protected Transport consumer;
|
||||||
|
|
||||||
protected Object lock = new Object();
|
protected final Object lock = new Object();
|
||||||
protected Command receivedCommand;
|
protected Command receivedCommand;
|
||||||
protected TransportServer server;
|
protected TransportServer server;
|
||||||
protected boolean large;
|
protected boolean large;
|
||||||
|
@ -251,10 +251,10 @@ public abstract class UdpTestSupport extends TestCase implements TransportListen
|
||||||
Command answer = null;
|
Command answer = null;
|
||||||
synchronized (lock) {
|
synchronized (lock) {
|
||||||
answer = receivedCommand;
|
answer = receivedCommand;
|
||||||
if (answer == null) {
|
while (answer == null) {
|
||||||
lock.wait(waitForCommandTimeout);
|
lock.wait(waitForCommandTimeout);
|
||||||
|
answer = receivedCommand;
|
||||||
}
|
}
|
||||||
answer = receivedCommand;
|
|
||||||
}
|
}
|
||||||
|
|
||||||
assertNotNull("Should have received a Command by now!", answer);
|
assertNotNull("Should have received a Command by now!", answer);
|
||||||
|
|
|
@ -107,7 +107,7 @@ public class ConcurrentProducerDurableConsumerTest extends TestSupport {
|
||||||
|
|
||||||
// periodically start a durable sub that has a backlog
|
// periodically start a durable sub that has a backlog
|
||||||
final int consumersToActivate = 5;
|
final int consumersToActivate = 5;
|
||||||
final Object addConsumerSignal = new Object();
|
final CountDownLatch addConsumerSignal = new CountDownLatch(1);
|
||||||
Executors.newCachedThreadPool(new ThreadFactory() {
|
Executors.newCachedThreadPool(new ThreadFactory() {
|
||||||
@Override
|
@Override
|
||||||
public Thread newThread(Runnable r) {
|
public Thread newThread(Runnable r) {
|
||||||
|
@ -120,9 +120,7 @@ public class ConcurrentProducerDurableConsumerTest extends TestSupport {
|
||||||
MessageConsumer consumer = null;
|
MessageConsumer consumer = null;
|
||||||
for (int i = 0; i < consumersToActivate; i++) {
|
for (int i = 0; i < consumersToActivate; i++) {
|
||||||
LOG.info("Waiting for add signal from producer...");
|
LOG.info("Waiting for add signal from producer...");
|
||||||
synchronized (addConsumerSignal) {
|
addConsumerSignal.await(30, TimeUnit.MINUTES);
|
||||||
addConsumerSignal.wait(30 * 60 * 1000);
|
|
||||||
}
|
|
||||||
TimedMessageListener listener = new TimedMessageListener();
|
TimedMessageListener listener = new TimedMessageListener();
|
||||||
consumer = createDurableSubscriber(factory.createConnection(), destination, "consumer" + (i + 1));
|
consumer = createDurableSubscriber(factory.createConnection(), destination, "consumer" + (i + 1));
|
||||||
LOG.info("Created consumer " + consumer);
|
LOG.info("Created consumer " + consumer);
|
||||||
|
@ -254,7 +252,7 @@ public class ConcurrentProducerDurableConsumerTest extends TestSupport {
|
||||||
final int numIterations,
|
final int numIterations,
|
||||||
Session session,
|
Session session,
|
||||||
MessageProducer producer,
|
MessageProducer producer,
|
||||||
Object addConsumerSignal) throws Exception {
|
CountDownLatch addConsumerSignal) throws Exception {
|
||||||
long start;
|
long start;
|
||||||
long count = 0;
|
long count = 0;
|
||||||
double batchMax = 0, max = 0, sum = 0;
|
double batchMax = 0, max = 0, sum = 0;
|
||||||
|
@ -269,10 +267,8 @@ public class ConcurrentProducerDurableConsumerTest extends TestSupport {
|
||||||
max = Math.max(max, (System.currentTimeMillis() - singleSendstart));
|
max = Math.max(max, (System.currentTimeMillis() - singleSendstart));
|
||||||
if (++count % 500 == 0) {
|
if (++count % 500 == 0) {
|
||||||
if (addConsumerSignal != null) {
|
if (addConsumerSignal != null) {
|
||||||
synchronized (addConsumerSignal) {
|
addConsumerSignal.countDown();
|
||||||
addConsumerSignal.notifyAll();
|
LOG.info("Signalled add consumer");
|
||||||
LOG.info("Signalled add consumer");
|
|
||||||
}
|
|
||||||
}
|
}
|
||||||
};
|
};
|
||||||
if (count % 5000 == 0) {
|
if (count % 5000 == 0) {
|
||||||
|
|
|
@ -95,7 +95,7 @@ public class ConcurrentProducerQueueConsumerTest extends TestSupport
|
||||||
|
|
||||||
// periodically start a queue consumer
|
// periodically start a queue consumer
|
||||||
final int consumersToActivate = 5;
|
final int consumersToActivate = 5;
|
||||||
final Object addConsumerSignal = new Object();
|
final CountDownLatch addConsumerSignal = new CountDownLatch(1);
|
||||||
Executors.newCachedThreadPool(new ThreadFactory() {
|
Executors.newCachedThreadPool(new ThreadFactory() {
|
||||||
@Override
|
@Override
|
||||||
public Thread newThread(Runnable r) {
|
public Thread newThread(Runnable r) {
|
||||||
|
@ -108,9 +108,7 @@ public class ConcurrentProducerQueueConsumerTest extends TestSupport
|
||||||
MessageConsumer consumer = null;
|
MessageConsumer consumer = null;
|
||||||
for (int i = 0; i < consumersToActivate; i++) {
|
for (int i = 0; i < consumersToActivate; i++) {
|
||||||
LOG.info("Waiting for add signal from producer...");
|
LOG.info("Waiting for add signal from producer...");
|
||||||
synchronized (addConsumerSignal) {
|
addConsumerSignal.await(30, TimeUnit.MINUTES);
|
||||||
addConsumerSignal.wait(30 * 60 * 1000);
|
|
||||||
}
|
|
||||||
TimedMessageListener listener = new TimedMessageListener();
|
TimedMessageListener listener = new TimedMessageListener();
|
||||||
consumer = createConsumer(factory.createConnection(), destination);
|
consumer = createConsumer(factory.createConnection(), destination);
|
||||||
LOG.info("Created consumer " + consumer);
|
LOG.info("Created consumer " + consumer);
|
||||||
|
@ -241,7 +239,7 @@ public class ConcurrentProducerQueueConsumerTest extends TestSupport
|
||||||
final int numIterations,
|
final int numIterations,
|
||||||
Session session,
|
Session session,
|
||||||
MessageProducer producer,
|
MessageProducer producer,
|
||||||
Object addConsumerSignal) throws Exception {
|
CountDownLatch addConsumerSignal) throws Exception {
|
||||||
long start;
|
long start;
|
||||||
long count = 0;
|
long count = 0;
|
||||||
double batchMax = 0, max = 0, sum = 0;
|
double batchMax = 0, max = 0, sum = 0;
|
||||||
|
@ -257,10 +255,8 @@ public class ConcurrentProducerQueueConsumerTest extends TestSupport
|
||||||
max = Math.max(max, (System.currentTimeMillis() - singleSendstart));
|
max = Math.max(max, (System.currentTimeMillis() - singleSendstart));
|
||||||
if (++count % 500 == 0) {
|
if (++count % 500 == 0) {
|
||||||
if (addConsumerSignal != null) {
|
if (addConsumerSignal != null) {
|
||||||
synchronized (addConsumerSignal) {
|
addConsumerSignal.countDown();
|
||||||
addConsumerSignal.notifyAll();
|
LOG.info("Signalled add consumer");
|
||||||
LOG.info("Signalled add consumer");
|
|
||||||
}
|
|
||||||
}
|
}
|
||||||
}
|
}
|
||||||
;
|
;
|
||||||
|
|
|
@ -44,7 +44,7 @@ public class MultiBrokersMultiClientsTest extends JmsMultipleBrokersTestSupport
|
||||||
private static final Logger LOG = LoggerFactory.getLogger(MultiBrokersMultiClientsTest.class);
|
private static final Logger LOG = LoggerFactory.getLogger(MultiBrokersMultiClientsTest.class);
|
||||||
|
|
||||||
protected Map<String, MessageConsumer> consumerMap;
|
protected Map<String, MessageConsumer> consumerMap;
|
||||||
Map<Thread, Throwable> unhandeledExceptions = new HashMap<Thread, Throwable>();
|
final Map<Thread, Throwable> unhandeledExceptions = new HashMap<Thread, Throwable>();
|
||||||
|
|
||||||
public void testTopicAllConnected() throws Exception {
|
public void testTopicAllConnected() throws Exception {
|
||||||
bridgeAllBrokers();
|
bridgeAllBrokers();
|
||||||
|
|
|
@ -265,7 +265,7 @@ public class NoDuplicateOnTopicNetworkTest extends CombinationTestSupport {
|
||||||
private MessageConsumer consumer;
|
private MessageConsumer consumer;
|
||||||
private final String durableID = "DURABLE_ID";
|
private final String durableID = "DURABLE_ID";
|
||||||
|
|
||||||
private List<String> receivedStrings = Collections.synchronizedList(new ArrayList<String>());
|
private final List<String> receivedStrings = Collections.synchronizedList(new ArrayList<String>());
|
||||||
private int numMessages = 10;
|
private int numMessages = 10;
|
||||||
private CountDownLatch recievedLatch = new CountDownLatch(numMessages);
|
private CountDownLatch recievedLatch = new CountDownLatch(numMessages);
|
||||||
|
|
||||||
|
|
|
@ -47,8 +47,8 @@ public class ReliableReconnectTest extends org.apache.activemq.TestSupport {
|
||||||
protected int deliveryMode = DeliveryMode.PERSISTENT;
|
protected int deliveryMode = DeliveryMode.PERSISTENT;
|
||||||
protected String consumerClientId;
|
protected String consumerClientId;
|
||||||
protected Destination destination;
|
protected Destination destination;
|
||||||
protected AtomicBoolean closeBroker = new AtomicBoolean(false);
|
protected final AtomicBoolean closeBroker = new AtomicBoolean(false);
|
||||||
protected AtomicInteger messagesReceived = new AtomicInteger(0);
|
protected final AtomicInteger messagesReceived = new AtomicInteger(0);
|
||||||
protected BrokerService broker;
|
protected BrokerService broker;
|
||||||
protected int firstBatch = MESSAGE_COUNT / 10;
|
protected int firstBatch = MESSAGE_COUNT / 10;
|
||||||
private IdGenerator idGen = new IdGenerator();
|
private IdGenerator idGen = new IdGenerator();
|
||||||
|
@ -159,7 +159,7 @@ public class ReliableReconnectTest extends org.apache.activemq.TestSupport {
|
||||||
connection.close();
|
connection.close();
|
||||||
spawnConsumer();
|
spawnConsumer();
|
||||||
synchronized (closeBroker) {
|
synchronized (closeBroker) {
|
||||||
if (!closeBroker.get()) {
|
while (!closeBroker.get()) {
|
||||||
closeBroker.wait();
|
closeBroker.wait();
|
||||||
}
|
}
|
||||||
}
|
}
|
||||||
|
@ -168,7 +168,7 @@ public class ReliableReconnectTest extends org.apache.activemq.TestSupport {
|
||||||
startBroker(false);
|
startBroker(false);
|
||||||
// System.err.println("Started Broker again");
|
// System.err.println("Started Broker again");
|
||||||
synchronized (messagesReceived) {
|
synchronized (messagesReceived) {
|
||||||
if (messagesReceived.get() < MESSAGE_COUNT) {
|
while (messagesReceived.get() < MESSAGE_COUNT) {
|
||||||
messagesReceived.wait(60000);
|
messagesReceived.wait(60000);
|
||||||
}
|
}
|
||||||
}
|
}
|
||||||
|
|
|
@ -51,7 +51,7 @@ public class VerifyNetworkConsumersDisconnectTest extends JmsMultipleBrokersTest
|
||||||
public static final int TIMEOUT = 30000;
|
public static final int TIMEOUT = 30000;
|
||||||
|
|
||||||
protected Map<String, MessageConsumer> consumerMap;
|
protected Map<String, MessageConsumer> consumerMap;
|
||||||
Map<Thread, Throwable> unhandledExceptions = new HashMap<Thread, Throwable>();
|
final Map<Thread, Throwable> unhandledExceptions = new HashMap<Thread, Throwable>();
|
||||||
|
|
||||||
private void assertNoUnhandledExceptions() {
|
private void assertNoUnhandledExceptions() {
|
||||||
for( Entry<Thread, Throwable> e: unhandledExceptions.entrySet()) {
|
for( Entry<Thread, Throwable> e: unhandledExceptions.entrySet()) {
|
||||||
|
|
|
@ -140,20 +140,28 @@ public class MessageIdList extends Assert implements MessageListener {
|
||||||
|
|
||||||
long start = System.currentTimeMillis();
|
long start = System.currentTimeMillis();
|
||||||
|
|
||||||
for (int i = 0; i < messageCount; i++) {
|
synchronized (semaphore)
|
||||||
try {
|
{
|
||||||
if (hasReceivedMessages(messageCount)) {
|
for (int i = 0; i < messageCount; i++)
|
||||||
break;
|
{
|
||||||
}
|
try
|
||||||
long duration = System.currentTimeMillis() - start;
|
{
|
||||||
if (duration >= maximumDuration) {
|
if (hasReceivedMessages(messageCount))
|
||||||
break;
|
{
|
||||||
}
|
break;
|
||||||
synchronized (semaphore) {
|
}
|
||||||
|
long duration = System.currentTimeMillis() - start;
|
||||||
|
if (duration >= maximumDuration)
|
||||||
|
{
|
||||||
|
break;
|
||||||
|
}
|
||||||
|
|
||||||
semaphore.wait(maximumDuration - duration);
|
semaphore.wait(maximumDuration - duration);
|
||||||
}
|
}
|
||||||
} catch (InterruptedException e) {
|
catch (InterruptedException e)
|
||||||
LOG.info("Caught: " + e);
|
{
|
||||||
|
LOG.info("Caught: " + e);
|
||||||
|
}
|
||||||
}
|
}
|
||||||
}
|
}
|
||||||
long end = System.currentTimeMillis() - start;
|
long end = System.currentTimeMillis() - start;
|
||||||
|
|
Loading…
Reference in New Issue