You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@activemq.apache.org by ch...@apache.org on 2006/03/03 16:36:51 UTC

svn commit: r382869 [4/4] - in /incubator/activemq/trunk: activemq-core/src/main/java/org/apache/activemq/ activemq-core/src/main/java/org/apache/activemq/advisory/ activemq-core/src/main/java/org/apache/activemq/broker/ activemq-core/src/main/java/org...

Modified: incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/broker/BrokerTestSupport.java
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/broker/BrokerTestSupport.java?rev=382869&r1=382868&r2=382869&view=diff
==============================================================================
--- incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/broker/BrokerTestSupport.java (original)
+++ incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/broker/BrokerTestSupport.java Fri Mar  3 07:36:38 2006
@@ -91,7 +91,7 @@
         super.tearDown();
     }
     
-    protected ConsumerInfo createConsumerInfo(SessionInfo sessionInfo, ActiveMQDestination destination) throws Throwable {
+    protected ConsumerInfo createConsumerInfo(SessionInfo sessionInfo, ActiveMQDestination destination) throws Exception {
         ConsumerInfo info = new ConsumerInfo(sessionInfo, ++idGenerator);
         info.setBrowser(false);
         info.setDestination(destination);
@@ -104,17 +104,17 @@
         return consumerInfo.createRemoveCommand();
     }
 
-    protected ProducerInfo createProducerInfo(SessionInfo sessionInfo) throws Throwable {
+    protected ProducerInfo createProducerInfo(SessionInfo sessionInfo) throws Exception {
         ProducerInfo info = new ProducerInfo(sessionInfo, ++idGenerator);
         return info;
     }
 
-    protected SessionInfo createSessionInfo(ConnectionInfo connectionInfo) throws Throwable {
+    protected SessionInfo createSessionInfo(ConnectionInfo connectionInfo) throws Exception {
         SessionInfo info = new SessionInfo(connectionInfo, ++idGenerator);
         return info;
     }
 
-    protected ConnectionInfo createConnectionInfo() throws Throwable {
+    protected ConnectionInfo createConnectionInfo() throws Exception {
         ConnectionInfo info = new ConnectionInfo();
         info.setConnectionId(new ConnectionId("connection:"+(++idGenerator)));
         info.setClientId( info.getConnectionId().getValue() );
@@ -220,7 +220,7 @@
         return info;
     }
 
-    protected int countMessagesInQueue(StubConnection connection, ConnectionInfo connectionInfo, ActiveMQDestination destination) throws Throwable {
+    protected int countMessagesInQueue(StubConnection connection, ConnectionInfo connectionInfo, ActiveMQDestination destination) throws Exception {
         
         SessionInfo sessionInfo = createSessionInfo(connectionInfo);
         connection.send(sessionInfo);
@@ -266,7 +266,7 @@
         return info;
     }
     
-    protected ActiveMQDestination createDestinationInfo(StubConnection connection, ConnectionInfo connectionInfo1, byte destinationType) throws Throwable {
+    protected ActiveMQDestination createDestinationInfo(StubConnection connection, ConnectionInfo connectionInfo1, byte destinationType) throws Exception {
         if( (destinationType & ActiveMQDestination.TEMP_MASK)!=0 ) {
             DestinationInfo info = createTempDestinationInfo(connectionInfo1, destinationType);
             connection.send(info);

Modified: incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/broker/MarshallingBrokerTest.java
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/broker/MarshallingBrokerTest.java?rev=382869&r1=382868&r2=382869&view=diff
==============================================================================
--- incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/broker/MarshallingBrokerTest.java (original)
+++ incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/broker/MarshallingBrokerTest.java Fri Mar  3 07:36:38 2006
@@ -43,14 +43,14 @@
     
     protected StubConnection createConnection() throws Exception {
         return new StubConnection(broker) {
-            public Response request(Command command) throws Throwable {
+            public Response request(Command command) throws Exception {
                 Response r = super.request((Command) wireFormat.unmarshal(wireFormat.marshal(command)));
                 if( r != null ) {
                     r = (Response) wireFormat.unmarshal(wireFormat.marshal(r));
                 }
                 return r;
             }
-            public void send(Command command) throws Throwable {
+            public void send(Command command) throws Exception {
                 super.send((Command) wireFormat.unmarshal(wireFormat.marshal(command)));
             }
             protected void dispatch(Command command) throws InterruptedException, IOException {

Modified: incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/broker/RecoveryBrokerTest.java
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/broker/RecoveryBrokerTest.java?rev=382869&r1=382868&r2=382869&view=diff
==============================================================================
--- incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/broker/RecoveryBrokerTest.java (original)
+++ incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/broker/RecoveryBrokerTest.java Fri Mar  3 07:36:38 2006
@@ -38,7 +38,7 @@
  */
 public class RecoveryBrokerTest extends BrokerRestartTestSupport {
         
-    public void testConsumedQueuePersistentMessagesLostOnRestart() throws Throwable {
+    public void testConsumedQueuePersistentMessagesLostOnRestart() throws Exception {
         
         ActiveMQDestination destination = new ActiveMQQueue("TEST");
         
@@ -80,7 +80,7 @@
         assertNull(m);        
     }
 
-    public void testQueuePersistentUncommitedMessagesLostOnRestart() throws Throwable {
+    public void testQueuePersistentUncommitedMessagesLostOnRestart() throws Exception {
         
         ActiveMQDestination destination = new ActiveMQQueue("TEST");
         
@@ -123,7 +123,7 @@
         assertNull(m);        
     }
 
-    public void testTopicDurableConsumerHoldsPersistentMessageAfterRestart() throws Throwable {
+    public void testTopicDurableConsumerHoldsPersistentMessageAfterRestart() throws Exception {
         
         ActiveMQDestination destination = new ActiveMQTopic("TEST");
         
@@ -177,7 +177,7 @@
         assertNoMessagesLeft(connection2);
     }
 
-    public void testQueuePersistentMessagesNotLostOnRestart() throws Throwable {
+    public void testQueuePersistentMessagesNotLostOnRestart() throws Exception {
         
         ActiveMQDestination destination = new ActiveMQQueue("TEST");
         
@@ -211,7 +211,7 @@
         assertEquals( m.getMessageId(), message.getMessageId() );
     }
     
-    public void testQueueNonPersistentMessagesLostOnRestart() throws Throwable {
+    public void testQueueNonPersistentMessagesLostOnRestart() throws Exception {
         
         ActiveMQDestination destination = new ActiveMQQueue("TEST");
         
@@ -243,7 +243,7 @@
         assertNoMessagesLeft(connection);
     }
     
-    public void testQueuePersistentCommitedMessagesNotLostOnRestart() throws Throwable {
+    public void testQueuePersistentCommitedMessagesNotLostOnRestart() throws Exception {
         
         ActiveMQDestination destination = new ActiveMQQueue("TEST");
         
@@ -290,7 +290,7 @@
         assertNoMessagesLeft(connection);
     }
     
-    public void testQueuePersistentCommitedAcksNotLostOnRestart() throws Throwable {
+    public void testQueuePersistentCommitedAcksNotLostOnRestart() throws Exception {
         
         ActiveMQDestination destination = new ActiveMQQueue("TEST");
         
@@ -343,7 +343,7 @@
         assertNull(m);        
     }
     
-    public void testQueuePersistentUncommitedAcksLostOnRestart() throws Throwable {
+    public void testQueuePersistentUncommitedAcksLostOnRestart() throws Exception {
         
         ActiveMQDestination destination = new ActiveMQQueue("TEST");
         

Modified: incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/broker/StubConnection.java
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/broker/StubConnection.java?rev=382869&r1=382868&r2=382869&view=diff
==============================================================================
--- incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/broker/StubConnection.java (original)
+++ incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/broker/StubConnection.java Fri Mar  3 07:36:38 2006
@@ -26,6 +26,7 @@
 import org.apache.activemq.thread.TaskRunnerFactory;
 import org.apache.activemq.transport.DefaultTransportListener;
 import org.apache.activemq.transport.Transport;
+import org.apache.activemq.util.JMSExceptionSupport;
 import org.apache.activemq.util.ServiceSupport;
 import org.axiondb.engine.commands.ShutdownCommand;
 import edu.emory.mathcs.backport.java.util.concurrent.BlockingQueue;
@@ -91,7 +92,7 @@
         return dispatchQueue;
     }
 
-    public void send(Command command) throws Throwable {
+    public void send(Command command) throws Exception {
         if( command instanceof Message ) {
             Message message = (Message) command;
             message.setProducerId(message.getMessageId().getProducerId());
@@ -101,7 +102,7 @@
             Response response = connection.service(command);
             if (response != null && response.isException()) {
                 ExceptionResponse er = (ExceptionResponse) response;
-                throw er.getException();
+                throw JMSExceptionSupport.create(er.getException());
             }
         }
         else if (transport != null) {
@@ -109,7 +110,7 @@
         }
     }
 
-    public Response request(Command command) throws Throwable {
+    public Response request(Command command) throws Exception {
         if( command instanceof Message ) {
             Message message = (Message) command;
             message.setProducerId(message.getMessageId().getProducerId());
@@ -119,7 +120,7 @@
             Response response = connection.service(command);
             if (response != null && response.isException()) {
                 ExceptionResponse er = (ExceptionResponse) response;
-                throw er.getException();
+                throw JMSExceptionSupport.create(er.getException());
             }
             return response;
         }
@@ -127,7 +128,7 @@
             Response response = transport.request(command);
             if (response != null && response.isException()) {
                 ExceptionResponse er = (ExceptionResponse) response;
-                throw er.getException();
+                throw JMSExceptionSupport.create(er.getException());
             }
             return response;
         }

Modified: incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/broker/XARecoveryBrokerTest.java
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/broker/XARecoveryBrokerTest.java?rev=382869&r1=382868&r2=382869&view=diff
==============================================================================
--- incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/broker/XARecoveryBrokerTest.java (original)
+++ incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/broker/XARecoveryBrokerTest.java Fri Mar  3 07:36:38 2006
@@ -40,7 +40,7 @@
 public class XARecoveryBrokerTest extends BrokerRestartTestSupport {
         
     
-    public void testPreparedTransactionRecoveredOnRestart() throws Throwable {
+    public void testPreparedTransactionRecoveredOnRestart() throws Exception {
         
         ActiveMQDestination destination = new ActiveMQQueue("TEST");
         
@@ -107,7 +107,7 @@
         assertNoMessagesLeft(connection);
     }
 
-    public void testQueuePersistentCommitedMessagesNotLostOnRestart() throws Throwable {
+    public void testQueuePersistentCommitedMessagesNotLostOnRestart() throws Exception {
         
         ActiveMQDestination destination = new ActiveMQQueue("TEST");
         
@@ -154,7 +154,7 @@
         assertNoMessagesLeft(connection);
     }
     
-    public void testQueuePersistentCommitedAcksNotLostOnRestart() throws Throwable {
+    public void testQueuePersistentCommitedAcksNotLostOnRestart() throws Exception {
         
         ActiveMQDestination destination = new ActiveMQQueue("TEST");
         
@@ -207,7 +207,7 @@
         assertNull(m);        
     }
     
-    public void testQueuePersistentUncommittedAcksLostOnRestart() throws Throwable {
+    public void testQueuePersistentUncommittedAcksLostOnRestart() throws Exception {
         
         ActiveMQDestination destination = new ActiveMQQueue("TEST");
         

Modified: incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/broker/advisory/AdvisoryBrokerTest.java
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/broker/advisory/AdvisoryBrokerTest.java?rev=382869&r1=382868&r2=382869&view=diff
==============================================================================
--- incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/broker/advisory/AdvisoryBrokerTest.java (original)
+++ incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/broker/advisory/AdvisoryBrokerTest.java Fri Mar  3 07:36:38 2006
@@ -32,7 +32,7 @@
 
 public class AdvisoryBrokerTest extends BrokerTestSupport {
      
-    public void testConnectionAdvisories() throws Throwable {
+    public void testConnectionAdvisories() throws Exception {
         
         ActiveMQDestination destination = AdvisorySupport.getConnectionAdvisoryTopic();
         
@@ -78,7 +78,7 @@
         assertNoMessagesLeft(connection1);
     }
 
-    public void testConsumerAdvisories() throws Throwable {
+    public void testConsumerAdvisories() throws Exception {
 
         ActiveMQDestination queue = new ActiveMQQueue("test");
         ActiveMQDestination destination = AdvisorySupport.getConsumerAdvisoryTopic(queue);
@@ -128,7 +128,7 @@
         assertNoMessagesLeft(connection2);
     }
 
-    public void testConsumerAdvisoriesReplayed() throws Throwable {
+    public void testConsumerAdvisoriesReplayed() throws Exception {
 
         ActiveMQDestination queue = new ActiveMQQueue("test");
         ActiveMQDestination destination = AdvisorySupport.getConsumerAdvisoryTopic(queue);
@@ -176,7 +176,7 @@
     }
 
 
-    public void testProducerAdvisories() throws Throwable {
+    public void testProducerAdvisories() throws Exception {
 
         ActiveMQDestination queue = new ActiveMQQueue("test");
         ActiveMQDestination destination = AdvisorySupport.getProducerAdvisoryTopic(queue);
@@ -225,7 +225,7 @@
         assertNoMessagesLeft(connection2);
     }
     
-    public void testProducerAdvisoriesReplayed() throws Throwable {
+    public void testProducerAdvisoriesReplayed() throws Exception {
 
         ActiveMQDestination queue = new ActiveMQQueue("test");
         ActiveMQDestination destination = AdvisorySupport.getProducerAdvisoryTopic(queue);
@@ -273,7 +273,7 @@
         assertNoMessagesLeft(connection2);
     }
 
-    public void testProducerAdvisoriesReplayedOnlyTargetNewConsumer() throws Throwable {
+    public void testProducerAdvisoriesReplayedOnlyTargetNewConsumer() throws Exception {
 
         ActiveMQDestination queue = new ActiveMQQueue("test");
         ActiveMQDestination destination = AdvisorySupport.getProducerAdvisoryTopic(queue);

Modified: incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/broker/store/LoadTester.java
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/broker/store/LoadTester.java?rev=382869&r1=382868&r2=382869&view=diff
==============================================================================
--- incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/broker/store/LoadTester.java (original)
+++ incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/broker/store/LoadTester.java Fri Mar  3 07:36:38 2006
@@ -54,7 +54,7 @@
         return factory;
     }
     
-    public void testQueueSendThenAddConsumer() throws Throwable {
+    public void testQueueSendThenAddConsumer() throws Exception {
         int MESSAGE_SIZE=1024*64;
         int PRODUCE_COUNT=10000;
         ProgressPrinter printer = new ProgressPrinter(PRODUCE_COUNT, 20);

Modified: incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/command/ActiveMQMessageTest.java
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/command/ActiveMQMessageTest.java?rev=382869&r1=382868&r2=382869&view=diff
==============================================================================
--- incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/command/ActiveMQMessageTest.java (original)
+++ incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/command/ActiveMQMessageTest.java Fri Mar  3 07:36:38 2006
@@ -401,7 +401,7 @@
             public byte getDataStructureType() {
                 return 0;
             }
-            public Response visit(CommandVisitor visitor) throws Throwable {
+            public Response visit(CommandVisitor visitor) throws Exception {
                 return null;
             }
         };

Modified: incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/network/DemandForwardingBridgeTest.java
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/network/DemandForwardingBridgeTest.java?rev=382869&r1=382868&r2=382869&view=diff
==============================================================================
--- incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/network/DemandForwardingBridgeTest.java (original)
+++ incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/network/DemandForwardingBridgeTest.java Fri Mar  3 07:36:38 2006
@@ -45,7 +45,7 @@
                 new Byte(ActiveMQDestination.QUEUE_TYPE), 
                 } );
     }
-    public void testSendThenAddConsumer() throws Throwable {
+    public void testSendThenAddConsumer() throws Exception {
         
         // Start a producer on local broker 
         StubConnection connection1 = createConnection();
@@ -94,7 +94,7 @@
                 new Byte(ActiveMQDestination.TOPIC_TYPE), 
                 } );
     }    
-    public void testAddConsumerThenSend() throws Throwable {
+    public void testAddConsumerThenSend() throws Exception {
         
         // Start a producer on local broker 
         StubConnection connection1 = createConnection();

Modified: incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/network/ForwardingBridgeTest.java
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/network/ForwardingBridgeTest.java?rev=382869&r1=382868&r2=382869&view=diff
==============================================================================
--- incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/network/ForwardingBridgeTest.java (original)
+++ incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/network/ForwardingBridgeTest.java Fri Mar  3 07:36:38 2006
@@ -46,7 +46,7 @@
                 new Byte(ActiveMQDestination.TOPIC_TYPE), 
                 } );
     }    
-    public void testAddConsumerThenSend() throws Throwable {
+    public void testAddConsumerThenSend() throws Exception {
         
         // Start a producer on local broker 
         StubConnection connection1 = createConnection();

Modified: incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/openwire/BooleanStreamTest.java
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/openwire/BooleanStreamTest.java?rev=382869&r1=382868&r2=382869&view=diff
==============================================================================
--- incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/openwire/BooleanStreamTest.java (original)
+++ incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/openwire/BooleanStreamTest.java Fri Mar  3 07:36:38 2006
@@ -39,7 +39,7 @@
         public boolean getBooleanValueFor(int index, int count);
     }
 
-    public void testBooleanMarshallingUsingAllTrue() throws Throwable {
+    public void testBooleanMarshallingUsingAllTrue() throws Exception {
         testBooleanStream(numberOfBytes, new BooleanValueSet() {
             public boolean getBooleanValueFor(int index, int count) {
                 return true;
@@ -47,7 +47,7 @@
         });
     }
 
-    public void testBooleanMarshallingUsingAllFalse() throws Throwable {
+    public void testBooleanMarshallingUsingAllFalse() throws Exception {
         testBooleanStream(numberOfBytes, new BooleanValueSet() {
             public boolean getBooleanValueFor(int index, int count) {
                 return false;
@@ -55,7 +55,7 @@
         });
     }
 
-    public void testBooleanMarshallingUsingOddAlternateTrueFalse() throws Throwable {
+    public void testBooleanMarshallingUsingOddAlternateTrueFalse() throws Exception {
         testBooleanStream(numberOfBytes, new BooleanValueSet() {
             public boolean getBooleanValueFor(int index, int count) {
                 return (index & 1) == 0;
@@ -63,7 +63,7 @@
         });
     }
     
-    public void testBooleanMarshallingUsingEvenAlternateTrueFalse() throws Throwable {
+    public void testBooleanMarshallingUsingEvenAlternateTrueFalse() throws Exception {
         testBooleanStream(numberOfBytes, new BooleanValueSet() {
             public boolean getBooleanValueFor(int index, int count) {
                 return (index & 1) != 0;

Modified: incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/proxy/ProxyConnectorTest.java
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/proxy/ProxyConnectorTest.java?rev=382869&r1=382868&r2=382869&view=diff
==============================================================================
--- incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/proxy/ProxyConnectorTest.java (original)
+++ incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/proxy/ProxyConnectorTest.java Fri Mar  3 07:36:38 2006
@@ -57,7 +57,7 @@
                 new Byte(ActiveMQDestination.TOPIC_TYPE), 
                 } );
     }
-    public void testSendAndConsume() throws Throwable {
+    public void testSendAndConsume() throws Exception {
         
         // Start a producer on local broker using the proxy
         StubConnection connection1 = createProxyConnection();

Modified: incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/transport/discovery/DiscoveryTransportBrokerTest.java
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/transport/discovery/DiscoveryTransportBrokerTest.java?rev=382869&r1=382868&r2=382869&view=diff
==============================================================================
--- incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/transport/discovery/DiscoveryTransportBrokerTest.java (original)
+++ incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/transport/discovery/DiscoveryTransportBrokerTest.java Fri Mar  3 07:36:38 2006
@@ -48,7 +48,7 @@
         super.setUp();
     }
 
-	public void testPublisherFailsOver() throws Throwable {
+	public void testPublisherFailsOver() throws Exception {
         ActiveMQDestination destination = new ActiveMQQueue("TEST");
         int deliveryMode = DeliveryMode.NON_PERSISTENT;
         

Modified: incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/transport/failover/FailoverTransportBrokerTest.java
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/transport/failover/FailoverTransportBrokerTest.java?rev=382869&r1=382868&r2=382869&view=diff
==============================================================================
--- incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/transport/failover/FailoverTransportBrokerTest.java (original)
+++ incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/transport/failover/FailoverTransportBrokerTest.java Fri Mar  3 07:36:38 2006
@@ -54,7 +54,7 @@
                 new ActiveMQTopic("TEST"), 
                 } );
     }    
-    public void testPublisherFailsOver() throws Throwable {
+    public void testPublisherFailsOver() throws Exception {
         
         // Start a normal consumer on the local broker 
         StubConnection connection1 = createConnection();

Modified: incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/transport/fanout/FanoutTransportBrokerTest.java
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/transport/fanout/FanoutTransportBrokerTest.java?rev=382869&r1=382868&r2=382869&view=diff
==============================================================================
--- incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/transport/fanout/FanoutTransportBrokerTest.java (original)
+++ incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/transport/fanout/FanoutTransportBrokerTest.java Fri Mar  3 07:36:38 2006
@@ -66,7 +66,7 @@
         addCombinationValues("destination", new Object[] { new ActiveMQQueue("TEST"), new ActiveMQTopic("TEST"), });
     }
 
-    public void xtestPublisherFansout() throws Throwable {
+    public void xtestPublisherFansout() throws Exception {
 
         // Start a normal consumer on the local broker
         StubConnection connection1 = createConnection();
@@ -113,7 +113,7 @@
                 new Integer(DeliveryMode.PERSISTENT) });
         addCombinationValues("destination", new Object[] { new ActiveMQQueue("TEST"), new ActiveMQTopic("TEST"), });
     }
-    public void testPublisherWaitsForServerToBeUp() throws Throwable {
+    public void testPublisherWaitsForServerToBeUp() throws Exception {
 
         // Start a normal consumer on the local broker
         StubConnection connection1 = createConnection();

Modified: incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/transport/vm/VMTransportEmbeddedBrokerTest.java
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/transport/vm/VMTransportEmbeddedBrokerTest.java?rev=382869&r1=382868&r2=382869&view=diff
==============================================================================
--- incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/transport/vm/VMTransportEmbeddedBrokerTest.java (original)
+++ incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/transport/vm/VMTransportEmbeddedBrokerTest.java Fri Mar  3 07:36:38 2006
@@ -45,7 +45,7 @@
         junit.textui.TestRunner.run(VMTransportEmbeddedBrokerTest.class);
     }
 
-    public void testConsumerPrefetchAtOne() throws Throwable {
+    public void testConsumerPrefetchAtOne() throws Exception {
         
         // Make sure the broker is created due to the connection being started.
         assertNull(BrokerRegistry.getInstance().lookup("localhost"));        

Modified: incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/xbean/ConnectorXBeanConfigTest.java
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/xbean/ConnectorXBeanConfigTest.java?rev=382869&r1=382868&r2=382869&view=diff
==============================================================================
--- incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/xbean/ConnectorXBeanConfigTest.java (original)
+++ incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/xbean/ConnectorXBeanConfigTest.java Fri Mar  3 07:36:38 2006
@@ -36,7 +36,7 @@
 
     protected BrokerService brokerService;
 
-    public void testConnectorConfiguredCorrectly() throws Throwable {
+    public void testConnectorConfiguredCorrectly() throws Exception {
         
         TransportConnector connector = (TransportConnector) brokerService.getTransportConnectors().get(0);
         

Modified: incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/xbean/JDBCPersistenceXBeanConfigTest.java
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/xbean/JDBCPersistenceXBeanConfigTest.java?rev=382869&r1=382868&r2=382869&view=diff
==============================================================================
--- incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/xbean/JDBCPersistenceXBeanConfigTest.java (original)
+++ incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/xbean/JDBCPersistenceXBeanConfigTest.java Fri Mar  3 07:36:38 2006
@@ -33,7 +33,7 @@
 
     protected BrokerService brokerService;
 
-    public void testManagmentContextConfiguredCorrectly() throws Throwable {
+    public void testManagmentContextConfiguredCorrectly() throws Exception {
 
         PersistenceAdapter persistenceAdapter = brokerService.getPersistenceAdapter();
         assertNotNull(persistenceAdapter);

Modified: incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/xbean/ManagementContextXBeanConfigTest.java
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/xbean/ManagementContextXBeanConfigTest.java?rev=382869&r1=382868&r2=382869&view=diff
==============================================================================
--- incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/xbean/ManagementContextXBeanConfigTest.java (original)
+++ incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/xbean/ManagementContextXBeanConfigTest.java Fri Mar  3 07:36:38 2006
@@ -36,7 +36,7 @@
 
     protected BrokerService brokerService;
 
-    public void testManagmentContextConfiguredCorrectly() throws Throwable {
+    public void testManagmentContextConfiguredCorrectly() throws Exception {
 
         assertEquals(2011, brokerService.getManagementContext().getConnectorPort());
         assertEquals("test.domain", brokerService.getManagementContext().getJmxDomainName());

Modified: incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/xbean/XBeanConfigTest.java
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/xbean/XBeanConfigTest.java?rev=382869&r1=382868&r2=382869&view=diff
==============================================================================
--- incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/xbean/XBeanConfigTest.java (original)
+++ incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/xbean/XBeanConfigTest.java Fri Mar  3 07:36:38 2006
@@ -46,7 +46,7 @@
     protected ConnectionContext context;
     protected ConnectionInfo info;
 
-    public void testBrokerConfiguredCorrectly() throws Throwable {
+    public void testBrokerConfiguredCorrectly() throws Exception {
 
 
         Topic topic = (Topic) broker.addDestination(context, new ActiveMQTopic("FOO.BAR"));

Modified: incubator/activemq/trunk/activemq-optional/src/main/java/org/apache/activemq/tool/AcidTestTool.java
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/activemq-optional/src/main/java/org/apache/activemq/tool/AcidTestTool.java?rev=382869&r1=382868&r2=382869&view=diff
==============================================================================
--- incubator/activemq/trunk/activemq-optional/src/main/java/org/apache/activemq/tool/AcidTestTool.java (original)
+++ incubator/activemq/trunk/activemq-optional/src/main/java/org/apache/activemq/tool/AcidTestTool.java Fri Mar  3 07:36:38 2006
@@ -16,13 +16,13 @@
  */
 package org.apache.activemq.tool;
 
-import edu.emory.mathcs.backport.java.util.concurrent.CountDownLatch;
-import edu.emory.mathcs.backport.java.util.concurrent.TimeUnit;
-import edu.emory.mathcs.backport.java.util.concurrent.atomic.AtomicBoolean;
-import edu.emory.mathcs.backport.java.util.concurrent.atomic.AtomicInteger;
-
-import org.apache.activemq.ActiveMQConnectionFactory;
-import org.apache.activemq.command.ActiveMQQueue;
+import java.io.IOException;
+import java.io.PrintWriter;
+import java.util.ArrayList;
+import java.util.Collections;
+import java.util.Iterator;
+import java.util.List;
+import java.util.Random;
 
 import javax.jms.BytesMessage;
 import javax.jms.Connection;
@@ -34,16 +34,16 @@
 import javax.jms.MessageProducer;
 import javax.jms.Session;
 
-import java.io.IOException;
-import java.io.PrintWriter;
-import java.util.ArrayList;
-import java.util.Collections;
-import java.util.Iterator;
-import java.util.List;
-import java.util.Random;
-
 import junit.framework.TestCase;
 
+import org.apache.activemq.ActiveMQConnectionFactory;
+import org.apache.activemq.command.ActiveMQQueue;
+
+import edu.emory.mathcs.backport.java.util.concurrent.CountDownLatch;
+import edu.emory.mathcs.backport.java.util.concurrent.TimeUnit;
+import edu.emory.mathcs.backport.java.util.concurrent.atomic.AtomicBoolean;
+import edu.emory.mathcs.backport.java.util.concurrent.atomic.AtomicInteger;
+
 /**
  * @version $Revision$
  */
@@ -250,7 +250,7 @@
     }
 
     /**
-     * @throws Throwable
+     * @throws Throwable 
      * @throws IOException
      * 
      */

Modified: incubator/activemq/trunk/assembly/src/test/java/org/apache/activemq/usecases/TwoBrokerMulticastQueueTest.java
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/assembly/src/test/java/org/apache/activemq/usecases/TwoBrokerMulticastQueueTest.java?rev=382869&r1=382868&r2=382869&view=diff
==============================================================================
--- incubator/activemq/trunk/assembly/src/test/java/org/apache/activemq/usecases/TwoBrokerMulticastQueueTest.java (original)
+++ incubator/activemq/trunk/assembly/src/test/java/org/apache/activemq/usecases/TwoBrokerMulticastQueueTest.java Fri Mar  3 07:36:38 2006
@@ -107,7 +107,7 @@
         });
     }
 
-    public void testSendReceive() throws Throwable {
+    public void testSendReceive() throws Exception {
         createMulticastBrokerNetwork();
         doSendReceiveTest();
     }
@@ -121,61 +121,61 @@
         });
     }
 
-    public void testMultipleConsumersConnect() throws Throwable {
+    public void testMultipleConsumersConnect() throws Exception {
         createMulticastBrokerNetwork();
         doMultipleConsumersConnectTest();
     }
 
-    public void testSendReceiveUsingFailover() throws Throwable {
+    public void testSendReceiveUsingFailover() throws Exception {
         sendUri = "failover:tcp://localhost:61616,tcp://localhost:61617";
         recvUri = "failover:tcp://localhost:61616,tcp://localhost:61617";
         createMulticastBrokerNetwork();
         doSendReceiveTest();
     }
 
-    public void testMultipleConsumersConnectUsingFailover() throws Throwable {
+    public void testMultipleConsumersConnectUsingFailover() throws Exception {
         sendUri = "failover:tcp://localhost:61616,tcp://localhost:61617";
         recvUri = "failover:tcp://localhost:61616,tcp://localhost:61617";
         createMulticastBrokerNetwork();
         doMultipleConsumersConnectTest();
     }
 
-    public void testSendReceiveUsingDiscovery() throws Throwable {
+    public void testSendReceiveUsingDiscovery() throws Exception {
         sendUri = "discovery:multicast://default";
         recvUri = "discovery:multicast://default";
         createMulticastBrokerNetwork();
         doSendReceiveTest();
     }
 
-    public void testMultipleConsumersConnectUsingDiscovery() throws Throwable {
+    public void testMultipleConsumersConnectUsingDiscovery() throws Exception {
         sendUri = "discovery:multicast://default";
         recvUri = "discovery:multicast://default";
         createMulticastBrokerNetwork();
         doMultipleConsumersConnectTest();
     }
 
-    public void testSendReceiveUsingAutoAssignFailover() throws Throwable {
+    public void testSendReceiveUsingAutoAssignFailover() throws Exception {
         sendUri = "failover:multicast://default";
         recvUri = "failover:multicast://default";
         createAutoAssignMulticastBrokerNetwork();
         doSendReceiveTest();
     }
 
-    public void testMultipleConsumersConnectUsingAutoAssignFailover() throws Throwable {
+    public void testMultipleConsumersConnectUsingAutoAssignFailover() throws Exception {
         sendUri = "failover:multicast://default";
         recvUri = "failover:multicast://default";
         createAutoAssignMulticastBrokerNetwork();
         doMultipleConsumersConnectTest();
     }
 
-    public void testSendReceiveUsingAutoAssignDiscovery() throws Throwable {
+    public void testSendReceiveUsingAutoAssignDiscovery() throws Exception {
         sendUri = "discovery:multicast://default";
         recvUri = "discovery:multicast://default";
         createAutoAssignMulticastBrokerNetwork();
         doSendReceiveTest();
     }
 
-    public void testMultipleConsumersConnectUsingAutoAssignDiscovery() throws Throwable {
+    public void testMultipleConsumersConnectUsingAutoAssignDiscovery() throws Exception {
         sendUri = "discovery:multicast://default";
         recvUri = "discovery:multicast://default";
         createAutoAssignMulticastBrokerNetwork();

Modified: incubator/activemq/trunk/openwire-dotnet/src/src.csproj
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/openwire-dotnet/src/src.csproj?rev=382869&r1=382868&r2=382869&view=diff
==============================================================================
--- incubator/activemq/trunk/openwire-dotnet/src/src.csproj (original)
+++ incubator/activemq/trunk/openwire-dotnet/src/src.csproj Fri Mar  3 07:36:38 2006
@@ -33,7 +33,6 @@
     </ItemGroup>
     <Import Project="$(MSBuildBinPath)\Microsoft.CSHARP.Targets"/>
     <ItemGroup>
-        <Compile Include="CommonAssemblyInfo.cs"/>
         <Compile Include="OpenWire.Client\BrokerException.cs"/>
         <Compile Include="OpenWire.Client\Commands\ActiveMQBytesMessage.cs"/>
         <Compile Include="OpenWire.Client\Commands\ActiveMQDestination.cs"/>