You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@activemq.apache.org by jg...@apache.org on 2010/07/16 19:14:15 UTC

svn commit: r964863 [3/3] - in /activemq/activemq-dotnet: Apache.NMS.ActiveMQ/trunk/ Apache.NMS.ActiveMQ/trunk/src/test/csharp/ Apache.NMS.ActiveMQ/trunk/src/test/csharp/Commands/ Apache.NMS.ActiveMQ/trunk/src/test/csharp/OpenWire/ Apache.NMS.ActiveMQ/...

Modified: activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/test/csharp/ConnectionTest.cs
URL: http://svn.apache.org/viewvc/activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/test/csharp/ConnectionTest.cs?rev=964863&r1=964862&r2=964863&view=diff
==============================================================================
--- activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/test/csharp/ConnectionTest.cs (original)
+++ activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/test/csharp/ConnectionTest.cs Fri Jul 16 17:14:12 2010
@@ -18,7 +18,6 @@
 using System;
 using System.Threading;
 using NUnit.Framework;
-using NUnit.Framework.Extensions;
 using Apache.NMS.Test;
 
 namespace Apache.NMS.Stomp.Test
@@ -72,10 +71,10 @@ namespace Apache.NMS.Stomp.Test
             }
         }
 
-        [RowTest]
-        [Row(true)]
-        [Row(false)]
-        public void CreateAndDisposeWithConsumer(bool disposeConsumer)
+        [Test]
+        public void CreateAndDisposeWithConsumer(
+			[Values(true, false)]
+			bool disposeConsumer)
         {
             using(IConnection connection = CreateConnection("DisposalTestConnection" + ":" + this.postfix))
             {
@@ -95,10 +94,10 @@ namespace Apache.NMS.Stomp.Test
             }
         }
 
-        [RowTest]
-        [Row(true)]
-        [Row(false)]
-        public void CreateAndDisposeWithProducer(bool disposeProducer)
+        [Test]
+        public void CreateAndDisposeWithProducer(
+			[Values(true, false)]
+			bool disposeProducer)
         {
             using(IConnection connection = CreateConnection("DisposalTestConnection" + ":" + this.postfix))
             {
@@ -118,12 +117,12 @@ namespace Apache.NMS.Stomp.Test
             }
         }
 
-        [RowTest]
-        [Row(MsgDeliveryMode.Persistent, DestinationType.Queue)]
-        [Row(MsgDeliveryMode.Persistent, DestinationType.Topic)]
-        [Row(MsgDeliveryMode.NonPersistent, DestinationType.Queue)]
-        [Row(MsgDeliveryMode.NonPersistent, DestinationType.Topic)]
-        public void TestStartAfterSend(MsgDeliveryMode deliveryMode, DestinationType destinationType)
+        [Test]
+        public void TestStartAfterSend(
+			[Values(MsgDeliveryMode.Persistent, MsgDeliveryMode.NonPersistent)]
+			MsgDeliveryMode deliveryMode,
+			[Values(DestinationType.Queue, DestinationType.Topic)]
+			DestinationType destinationType)
         {
             using(IConnection connection = CreateConnection(TEST_CLIENT_ID + ":" + this.postfix))
             {

Modified: activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/test/csharp/ConsumerTest.cs
URL: http://svn.apache.org/viewvc/activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/test/csharp/ConsumerTest.cs?rev=964863&r1=964862&r2=964863&view=diff
==============================================================================
--- activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/test/csharp/ConsumerTest.cs (original)
+++ activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/test/csharp/ConsumerTest.cs Fri Jul 16 17:14:12 2010
@@ -21,7 +21,6 @@ using Apache.NMS;
 using Apache.NMS.Util;
 using Apache.NMS.Test;
 using NUnit.Framework;
-using NUnit.Framework.Extensions;
 
 namespace Apache.NMS.Stomp.Test
 {

Modified: activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/test/csharp/DurableTest.cs
URL: http://svn.apache.org/viewvc/activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/test/csharp/DurableTest.cs?rev=964863&r1=964862&r2=964863&view=diff
==============================================================================
--- activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/test/csharp/DurableTest.cs (original)
+++ activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/test/csharp/DurableTest.cs Fri Jul 16 17:14:12 2010
@@ -18,7 +18,6 @@
 using System;
 using System.Threading;
 using NUnit.Framework;
-using NUnit.Framework.Extensions;
 using Apache.NMS.Util;
 using Apache.NMS.Test;
 
@@ -32,12 +31,11 @@ namespace Apache.NMS.Stomp.Test
         protected static string DURABLE_TOPIC = "TestDurableConsumerTopic";
         protected static string DURABLE_SELECTOR = "2 > 1";
 
-        [RowTest]
-        [Row(AcknowledgementMode.AutoAcknowledge)]
-        [Row(AcknowledgementMode.ClientAcknowledge)]
-        [Row(AcknowledgementMode.DupsOkAcknowledge)]
-        [Row(AcknowledgementMode.Transactional)]
-        public void TestSendWhileClosed(AcknowledgementMode ackMode)
+        [Test]
+        public void TestSendWhileClosed(
+			[Values(AcknowledgementMode.AutoAcknowledge, AcknowledgementMode.ClientAcknowledge,
+				AcknowledgementMode.DupsOkAcknowledge, AcknowledgementMode.Transactional)]
+			AcknowledgementMode ackMode)
         {
             string CLIENT_ID_AND_SUBSCIPTION = TEST_CLIENT_ID + ":" + new Random().Next();
 
@@ -99,12 +97,11 @@ namespace Apache.NMS.Stomp.Test
             }
         }
 
-        [RowTest]
-        [Row(AcknowledgementMode.AutoAcknowledge)]
-        [Row(AcknowledgementMode.ClientAcknowledge)]
-        [Row(AcknowledgementMode.DupsOkAcknowledge)]
-        [Row(AcknowledgementMode.Transactional)]
-        public void TestDurableConsumerSelectorChange(AcknowledgementMode ackMode)
+        [Test]
+        public void TestDurableConsumerSelectorChange(
+			[Values(AcknowledgementMode.AutoAcknowledge, AcknowledgementMode.ClientAcknowledge,
+				AcknowledgementMode.DupsOkAcknowledge, AcknowledgementMode.Transactional)]
+			AcknowledgementMode ackMode)
         {
             string CLIENT_ID_AND_SUBSCIPTION = TEST_CLIENT_ID + ":" + new Random().Next();
 
@@ -188,12 +185,11 @@ namespace Apache.NMS.Stomp.Test
             }
         }
 
-        [RowTest]
-        [Row(AcknowledgementMode.AutoAcknowledge)]
-        [Row(AcknowledgementMode.ClientAcknowledge)]
-        [Row(AcknowledgementMode.DupsOkAcknowledge)]
-        [Row(AcknowledgementMode.Transactional)]
-        public void TestDurableConsumer(AcknowledgementMode ackMode)
+        [Test]
+        public void TestDurableConsumer(
+			[Values(AcknowledgementMode.AutoAcknowledge, AcknowledgementMode.ClientAcknowledge,
+				AcknowledgementMode.DupsOkAcknowledge, AcknowledgementMode.Transactional)]
+			AcknowledgementMode ackMode)
         {
             string CLIENT_ID_AND_SUBSCIPTION = TEST_CLIENT_ID + ":" + new Random().Next();
 

Modified: activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/test/csharp/ExclusiveConsumerTest.cs
URL: http://svn.apache.org/viewvc/activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/test/csharp/ExclusiveConsumerTest.cs?rev=964863&r1=964862&r2=964863&view=diff
==============================================================================
--- activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/test/csharp/ExclusiveConsumerTest.cs (original)
+++ activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/test/csharp/ExclusiveConsumerTest.cs Fri Jul 16 17:14:12 2010
@@ -21,7 +21,6 @@ using Apache.NMS.Test;
 using Apache.NMS.Stomp;
 using Apache.NMS.Stomp.Commands;
 using NUnit.Framework;
-using NUnit.Framework.Extensions;
 
 namespace Apache.NMS.Stomp.Test
 {

Modified: activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/test/csharp/IndividualAckTest.cs
URL: http://svn.apache.org/viewvc/activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/test/csharp/IndividualAckTest.cs?rev=964863&r1=964862&r2=964863&view=diff
==============================================================================
--- activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/test/csharp/IndividualAckTest.cs (original)
+++ activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/test/csharp/IndividualAckTest.cs Fri Jul 16 17:14:12 2010
@@ -22,7 +22,6 @@ using Apache.NMS.Util;
 using Apache.NMS.Test;
 using Apache.NMS.Stomp.Commands;
 using NUnit.Framework;
-using NUnit.Framework.Extensions;
 
 namespace Apache.NMS.Stomp.Test
 {

Modified: activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/test/csharp/MapMessageTest.cs
URL: http://svn.apache.org/viewvc/activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/test/csharp/MapMessageTest.cs?rev=964863&r1=964862&r2=964863&view=diff
==============================================================================
--- activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/test/csharp/MapMessageTest.cs (original)
+++ activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/test/csharp/MapMessageTest.cs Fri Jul 16 17:14:12 2010
@@ -21,7 +21,6 @@ using Apache.NMS;
 using Apache.NMS.Test;
 using Apache.NMS.Util;
 using NUnit.Framework;
-using NUnit.Framework.Extensions;
 
 namespace Apache.NMS.Stomp.Test
 {
@@ -46,10 +45,10 @@ namespace Apache.NMS.Stomp.Test
         protected float m = 2.1F;
         protected double n = 2.3;
 
-        [RowTest]
-        [Row(MsgDeliveryMode.Persistent)]
-        [Row(MsgDeliveryMode.NonPersistent)]
-        public void SendReceiveMapMessage(MsgDeliveryMode deliveryMode)
+        [Test]
+        public void SendReceiveMapMessage(
+			[Values(MsgDeliveryMode.Persistent, MsgDeliveryMode.NonPersistent)]
+			MsgDeliveryMode deliveryMode)
         {
             using(IConnection connection = CreateConnection(TEST_CLIENT_ID + ":" + new Random().Next()))
             {
@@ -123,10 +122,10 @@ namespace Apache.NMS.Stomp.Test
             }
         }
 
-//        [RowTest]
-//        [Row(MsgDeliveryMode.Persistent)]
-//        [Row(MsgDeliveryMode.NonPersistent)]
-        public void SendReceiveNestedMapMessage(MsgDeliveryMode deliveryMode)
+//        [Test]
+        public void SendReceiveNestedMapMessage(
+			[Values(MsgDeliveryMode.Persistent, MsgDeliveryMode.NonPersistent)]
+			MsgDeliveryMode deliveryMode)
         {
             using(IConnection connection = CreateConnection(TEST_CLIENT_ID + ":" + new Random().Next()))
             {

Modified: activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/test/csharp/MessageListenerRedeliveryTest.cs
URL: http://svn.apache.org/viewvc/activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/test/csharp/MessageListenerRedeliveryTest.cs?rev=964863&r1=964862&r2=964863&view=diff
==============================================================================
--- activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/test/csharp/MessageListenerRedeliveryTest.cs (original)
+++ activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/test/csharp/MessageListenerRedeliveryTest.cs Fri Jul 16 17:14:12 2010
@@ -23,7 +23,6 @@ using Apache.NMS.Util;
 using Apache.NMS.Stomp;
 using Apache.NMS.Test;
 using NUnit.Framework;
-using NUnit.Framework.Extensions;
 
 namespace Apache.NMS.Stomp.Test
 {

Modified: activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/test/csharp/MessageTest.cs
URL: http://svn.apache.org/viewvc/activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/test/csharp/MessageTest.cs?rev=964863&r1=964862&r2=964863&view=diff
==============================================================================
--- activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/test/csharp/MessageTest.cs (original)
+++ activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/test/csharp/MessageTest.cs Fri Jul 16 17:14:12 2010
@@ -17,7 +17,6 @@
 
 using System;
 using NUnit.Framework;
-using NUnit.Framework.Extensions;
 using Apache.NMS.Util;
 using Apache.NMS.Test;
 
@@ -44,10 +43,10 @@ namespace Apache.NMS.Stomp.Test
         protected float		m = 2.1F;
         protected double	n = 2.3;
 
-        [RowTest]
-        [Row(MsgDeliveryMode.Persistent)]
-        [Row(MsgDeliveryMode.NonPersistent)]
-        public void SendReceiveMessageIdComparisonTest(MsgDeliveryMode deliveryMode)
+        [Test]
+        public void SendReceiveMessageIdComparisonTest(
+			[Values(MsgDeliveryMode.Persistent, MsgDeliveryMode.NonPersistent)]
+			MsgDeliveryMode deliveryMode)
         {
             using(IConnection connection = CreateConnection(TEST_CLIENT_ID + ":" + new Random().Next()))
             {
@@ -83,10 +82,10 @@ namespace Apache.NMS.Stomp.Test
             }
         }
 
-        [RowTest]
-        [Row(MsgDeliveryMode.Persistent)]
-        [Row(MsgDeliveryMode.NonPersistent)]
-        public void SendReceiveMessageProperties(MsgDeliveryMode deliveryMode)
+        [Test]
+        public void SendReceiveMessageProperties(
+			[Values(MsgDeliveryMode.Persistent, MsgDeliveryMode.NonPersistent)]
+			MsgDeliveryMode deliveryMode)
         {
             using(IConnection connection = CreateConnection(TEST_CLIENT_ID + ":" + new Random().Next()))
             {

Modified: activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/test/csharp/NMSConnectionFactoryTest.cs
URL: http://svn.apache.org/viewvc/activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/test/csharp/NMSConnectionFactoryTest.cs?rev=964863&r1=964862&r2=964863&view=diff
==============================================================================
--- activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/test/csharp/NMSConnectionFactoryTest.cs (original)
+++ activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/test/csharp/NMSConnectionFactoryTest.cs Fri Jul 16 17:14:12 2010
@@ -19,31 +19,30 @@ using System;
 using System.Net.Sockets;
 using Apache.NMS.Test;
 using NUnit.Framework;
-using NUnit.Framework.Extensions;
 
 namespace Apache.NMS.Stomp.Test
 {
     [TestFixture]
     public class NMSConnectionFactoryTest
     {
-        [RowTest]
+        [Test]
 #if !NETCF
-        [Row("stomp:tcp://${activemqhost}:61613")]
-        [Row("stomp:tcp://${activemqhost}:61613?connection.asyncsend=false")]
-        [Row("stomp:tcp://${activemqhost}:61613?connection.InvalidParameter=true", ExpectedException = typeof(NMSConnectionException))]
-        [Row("stomp:tcp://${activemqhost}:61613?connection.InvalidParameter=true", ExpectedException = typeof(NMSConnectionException))]
-        [Row("stomp:(tcp://${activemqhost}:61613)?connection.asyncSend=false", ExpectedException = typeof(NMSConnectionException))]
+        [TestCase("stomp:tcp://${activemqhost}:61613")]
+		[TestCase("stomp:tcp://${activemqhost}:61613?connection.asyncsend=false")]
+		[TestCase("stomp:tcp://${activemqhost}:61613?connection.InvalidParameter=true", ExpectedException = typeof(NMSConnectionException))]
+		[TestCase("stomp:tcp://${activemqhost}:61613?connection.InvalidParameter=true", ExpectedException = typeof(NMSConnectionException))]
+		[TestCase("stomp:(tcp://${activemqhost}:61613)?connection.asyncSend=false", ExpectedException = typeof(NMSConnectionException))]
 #endif
-        [Row("stomp:tcp://InvalidHost:61613", ExpectedException = typeof(NMSConnectionException))]
-        [Row("stomp:tcp://InvalidHost:61613", ExpectedException = typeof(NMSConnectionException))]
-        [Row("stomp:tcp://InvalidHost:61613?connection.asyncsend=false", ExpectedException = typeof(NMSConnectionException))]
-        [Row("ftp://${activemqhost}:61613", ExpectedException = typeof(NMSConnectionException))]
-        [Row("http://${activemqhost}:61613", ExpectedException = typeof(NMSConnectionException))]
-        [Row("discovery://${activemqhost}:6155", ExpectedException = typeof(NMSConnectionException))]
-        [Row("sms://${activemqhost}:61613", ExpectedException = typeof(NMSConnectionException))]
-        [Row("stomp:multicast://${activemqhost}:6155", ExpectedException = typeof(NMSConnectionException))]
-        [Row("(tcp://${activemqhost}:61613,tcp://${activemqhost}:61613)", ExpectedException = typeof(UriFormatException))]
-        [Row("tcp://${activemqhost}:61613,tcp://${activemqhost}:61613", ExpectedException = typeof(UriFormatException))]
+		[TestCase("stomp:tcp://InvalidHost:61613", ExpectedException = typeof(NMSConnectionException))]
+		[TestCase("stomp:tcp://InvalidHost:61613", ExpectedException = typeof(NMSConnectionException))]
+		[TestCase("stomp:tcp://InvalidHost:61613?connection.asyncsend=false", ExpectedException = typeof(NMSConnectionException))]
+		[TestCase("ftp://${activemqhost}:61613", ExpectedException = typeof(NMSConnectionException))]
+		[TestCase("http://${activemqhost}:61613", ExpectedException = typeof(NMSConnectionException))]
+		[TestCase("discovery://${activemqhost}:6155", ExpectedException = typeof(NMSConnectionException))]
+		[TestCase("sms://${activemqhost}:61613", ExpectedException = typeof(NMSConnectionException))]
+		[TestCase("stomp:multicast://${activemqhost}:6155", ExpectedException = typeof(NMSConnectionException))]
+		[TestCase("(tcp://${activemqhost}:61613,tcp://${activemqhost}:61613)", ExpectedException = typeof(UriFormatException))]
+		[TestCase("tcp://${activemqhost}:61613,tcp://${activemqhost}:61613", ExpectedException = typeof(UriFormatException))]
         public void TestURI(string connectionURI)
         {
             NMSConnectionFactory factory = new NMSConnectionFactory(NMSTestSupport.ReplaceEnvVar(connectionURI));
@@ -55,10 +54,9 @@ namespace Apache.NMS.Stomp.Test
             }
         }
 
-#if !NETCF
         [Test]
-#endif
-        public void TestURIForPrefetchHandling()
+		[Platform(Exclude = "NetCF")]
+		public void TestURIForPrefetchHandling()
         {
             string uri1 = "stomp:tcp://${activemqhost}:61613" +
                           "?nms.PrefetchPolicy.queuePrefetch=1" +

Modified: activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/test/csharp/NMSPropertyTest.cs
URL: http://svn.apache.org/viewvc/activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/test/csharp/NMSPropertyTest.cs?rev=964863&r1=964862&r2=964863&view=diff
==============================================================================
--- activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/test/csharp/NMSPropertyTest.cs (original)
+++ activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/test/csharp/NMSPropertyTest.cs Fri Jul 16 17:14:12 2010
@@ -19,7 +19,6 @@ using System;
 using Apache.NMS.Test;
 using Apache.NMS.Util;
 using NUnit.Framework;
-using NUnit.Framework.Extensions;
 
 namespace Apache.NMS.Stomp.Test
 {
@@ -37,10 +36,10 @@ namespace Apache.NMS.Stomp.Test
         protected String groupID = "BarGroup";
         protected int groupSeq = 1;
 
-        [RowTest]
-        [Row(MsgDeliveryMode.Persistent)]
-        [Row(MsgDeliveryMode.NonPersistent)]
-        public void SendReceiveNMSProperties(MsgDeliveryMode deliveryMode)
+        [Test]
+        public void SendReceiveNMSProperties(
+			[Values(MsgDeliveryMode.Persistent, MsgDeliveryMode.NonPersistent)]
+			MsgDeliveryMode deliveryMode)
         {
             using(IConnection connection = CreateConnection(TEST_CLIENT_ID + ":" + new Random().Next()))
             {

Modified: activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/test/csharp/ProducerTest.cs
URL: http://svn.apache.org/viewvc/activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/test/csharp/ProducerTest.cs?rev=964863&r1=964862&r2=964863&view=diff
==============================================================================
--- activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/test/csharp/ProducerTest.cs (original)
+++ activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/test/csharp/ProducerTest.cs Fri Jul 16 17:14:12 2010
@@ -21,7 +21,6 @@ using Apache.NMS;
 using Apache.NMS.Test;
 using Apache.NMS.Util;
 using NUnit.Framework;
-using NUnit.Framework.Extensions;
 
 namespace Apache.NMS.Stomp.Test
 {

Modified: activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/test/csharp/Protocol/XmlPrimitiveMapMarshalerTest.cs
URL: http://svn.apache.org/viewvc/activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/test/csharp/Protocol/XmlPrimitiveMapMarshalerTest.cs?rev=964863&r1=964862&r2=964863&view=diff
==============================================================================
--- activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/test/csharp/Protocol/XmlPrimitiveMapMarshalerTest.cs (original)
+++ activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/test/csharp/Protocol/XmlPrimitiveMapMarshalerTest.cs Fri Jul 16 17:14:12 2010
@@ -23,7 +23,6 @@ using Apache.NMS.Util;
 using Apache.NMS.Test;
 using Apache.NMS.Stomp.Protocol;
 using NUnit.Framework;
-using NUnit.Framework.Extensions;
 
 namespace Apache.NMS.Stomp.Test.Protocol
 {

Modified: activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/test/csharp/StompQueueTransactionTest.cs
URL: http://svn.apache.org/viewvc/activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/test/csharp/StompQueueTransactionTest.cs?rev=964863&r1=964862&r2=964863&view=diff
==============================================================================
--- activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/test/csharp/StompQueueTransactionTest.cs (original)
+++ activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/test/csharp/StompQueueTransactionTest.cs Fri Jul 16 17:14:12 2010
@@ -21,7 +21,6 @@ using System.Collections.Generic;
 using Apache.NMS.Test;
 using Apache.NMS.Stomp;
 using NUnit.Framework;
-using NUnit.Framework.Extensions;
 
 namespace Apache.NMS.Stomp.Test
 {

Modified: activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/test/csharp/StompRedeliveryPolicyTest.cs
URL: http://svn.apache.org/viewvc/activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/test/csharp/StompRedeliveryPolicyTest.cs?rev=964863&r1=964862&r2=964863&view=diff
==============================================================================
--- activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/test/csharp/StompRedeliveryPolicyTest.cs (original)
+++ activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/test/csharp/StompRedeliveryPolicyTest.cs Fri Jul 16 17:14:12 2010
@@ -23,7 +23,6 @@ using Apache.NMS.Policies;
 using Apache.NMS.Stomp;
 using Apache.NMS.Stomp.Commands;
 using NUnit.Framework;
-using NUnit.Framework.Extensions;
 
 namespace Apache.NMS.Stomp.Test
 {

Modified: activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/test/csharp/StompTopicTransactionTest.cs
URL: http://svn.apache.org/viewvc/activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/test/csharp/StompTopicTransactionTest.cs?rev=964863&r1=964862&r2=964863&view=diff
==============================================================================
--- activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/test/csharp/StompTopicTransactionTest.cs (original)
+++ activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/test/csharp/StompTopicTransactionTest.cs Fri Jul 16 17:14:12 2010
@@ -21,7 +21,6 @@ using System.Collections.Generic;
 using Apache.NMS.Test;
 using Apache.NMS.Stomp;
 using NUnit.Framework;
-using NUnit.Framework.Extensions;
 
 namespace Apache.NMS.Stomp.Test
 {

Modified: activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/test/csharp/StompTransactionTestSupport.cs
URL: http://svn.apache.org/viewvc/activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/test/csharp/StompTransactionTestSupport.cs?rev=964863&r1=964862&r2=964863&view=diff
==============================================================================
--- activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/test/csharp/StompTransactionTestSupport.cs (original)
+++ activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/test/csharp/StompTransactionTestSupport.cs Fri Jul 16 17:14:12 2010
@@ -22,7 +22,6 @@ using Apache.NMS.Test;
 using Apache.NMS.Stomp;
 using Apache.NMS.Stomp.Commands;
 using NUnit.Framework;
-using NUnit.Framework.Extensions;
 
 namespace Apache.NMS.Stomp.Test
 {

Modified: activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/test/csharp/TempDestinationTest.cs
URL: http://svn.apache.org/viewvc/activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/test/csharp/TempDestinationTest.cs?rev=964863&r1=964862&r2=964863&view=diff
==============================================================================
--- activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/test/csharp/TempDestinationTest.cs (original)
+++ activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/test/csharp/TempDestinationTest.cs Fri Jul 16 17:14:12 2010
@@ -21,7 +21,6 @@ using System.Collections;
 using Apache.NMS.Util;
 using Apache.NMS.Test;
 using NUnit.Framework;
-using NUnit.Framework.Extensions;
 
 namespace Apache.NMS.Stomp.Test
 {

Modified: activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/test/csharp/TextMessageTest.cs
URL: http://svn.apache.org/viewvc/activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/test/csharp/TextMessageTest.cs?rev=964863&r1=964862&r2=964863&view=diff
==============================================================================
--- activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/test/csharp/TextMessageTest.cs (original)
+++ activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/test/csharp/TextMessageTest.cs Fri Jul 16 17:14:12 2010
@@ -19,7 +19,6 @@ using System;
 using Apache.NMS.Util;
 using Apache.NMS.Test;
 using NUnit.Framework;
-using NUnit.Framework.Extensions;
 
 namespace Apache.NMS.Stomp.Test
 {
@@ -29,10 +28,10 @@ namespace Apache.NMS.Stomp.Test
         protected static string DESTINATION_NAME = "TextMessageDestination";
         protected static string TEST_CLIENT_ID = "TextMessageClientId";
 
-        [RowTest]
-        [Row(MsgDeliveryMode.Persistent)]
-        [Row(MsgDeliveryMode.NonPersistent)]
-        public void SendReceiveTextMessage(MsgDeliveryMode deliveryMode)
+        [Test]
+        public void SendReceiveTextMessage(
+			[Values(MsgDeliveryMode.Persistent, MsgDeliveryMode.NonPersistent)]
+			MsgDeliveryMode deliveryMode)
         {
             using(IConnection connection = CreateConnection(TEST_CLIENT_ID + ":" + new Random().Next()))
             {

Modified: activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/test/csharp/TransactionTest.cs
URL: http://svn.apache.org/viewvc/activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/test/csharp/TransactionTest.cs?rev=964863&r1=964862&r2=964863&view=diff
==============================================================================
--- activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/test/csharp/TransactionTest.cs (original)
+++ activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/test/csharp/TransactionTest.cs Fri Jul 16 17:14:12 2010
@@ -21,7 +21,6 @@ using System.Collections;
 using Apache.NMS.Util;
 using Apache.NMS.Test;
 using NUnit.Framework;
-using NUnit.Framework.Extensions;
 
 namespace Apache.NMS.Stomp.Test
 {
@@ -32,10 +31,10 @@ namespace Apache.NMS.Stomp.Test
         protected static string TEST_CLIENT_ID = "TransactionTestClientId";
         protected static string TEST_CLIENT_ID2 = "TransactionTestClientId2";
 
-        [RowTest]
-        [Row(MsgDeliveryMode.Persistent)]
-        [Row(MsgDeliveryMode.NonPersistent)]
-        public void TestSendRollback(MsgDeliveryMode deliveryMode)
+        [Test]
+        public void TestSendRollback(
+			[Values(MsgDeliveryMode.Persistent, MsgDeliveryMode.NonPersistent)]
+			MsgDeliveryMode deliveryMode)
         {
             using(IConnection connection = CreateConnection(TEST_CLIENT_ID + ":" + new Random().Next()))
             {
@@ -75,10 +74,10 @@ namespace Apache.NMS.Stomp.Test
             }
         }
 
-        [RowTest]
-        [Row(MsgDeliveryMode.Persistent)]
-        [Row(MsgDeliveryMode.NonPersistent)]
-        public void TestSendSessionClose(MsgDeliveryMode deliveryMode)
+        [Test]
+        public void TestSendSessionClose(
+			[Values(MsgDeliveryMode.Persistent, MsgDeliveryMode.NonPersistent)]
+			MsgDeliveryMode deliveryMode)
         {
             ITextMessage firstMsgSend;
             ITextMessage secondMsgSend;
@@ -163,10 +162,10 @@ namespace Apache.NMS.Stomp.Test
             }
         }
 
-        [RowTest]
-        [Row(MsgDeliveryMode.Persistent)]
-        [Row(MsgDeliveryMode.NonPersistent)]
-        public void TestReceiveRollback(MsgDeliveryMode deliveryMode)
+        [Test]
+        public void TestReceiveRollback(
+			[Values(MsgDeliveryMode.Persistent, MsgDeliveryMode.NonPersistent)]
+			MsgDeliveryMode deliveryMode)
         {
             using(IConnection connection = CreateConnection(TEST_CLIENT_ID + ":" + new Random().Next()))
             {
@@ -206,10 +205,10 @@ namespace Apache.NMS.Stomp.Test
         }
 
 
-        [RowTest]
-        [Row(MsgDeliveryMode.Persistent)]
-        [Row(MsgDeliveryMode.NonPersistent)]
-        public void TestReceiveTwoThenRollback(MsgDeliveryMode deliveryMode)
+        [Test]
+        public void TestReceiveTwoThenRollback(
+			[Values(MsgDeliveryMode.Persistent, MsgDeliveryMode.NonPersistent)]
+			MsgDeliveryMode deliveryMode)
         {
             using(IConnection connection = CreateConnection(TEST_CLIENT_ID + ":" + new Random().Next()))
             {
@@ -250,12 +249,12 @@ namespace Apache.NMS.Stomp.Test
             }
         }
 
-        [RowTest]
-        [Row(AcknowledgementMode.AutoAcknowledge, MsgDeliveryMode.Persistent)]
-        [Row(AcknowledgementMode.AutoAcknowledge, MsgDeliveryMode.NonPersistent)]
-        [Row(AcknowledgementMode.ClientAcknowledge, MsgDeliveryMode.Persistent)]
-        [Row(AcknowledgementMode.ClientAcknowledge, MsgDeliveryMode.NonPersistent)]
-        public void TestSendCommitNonTransaction(AcknowledgementMode ackMode, MsgDeliveryMode deliveryMode)
+        [Test]
+        public void TestSendCommitNonTransaction(
+			[Values(AcknowledgementMode.AutoAcknowledge, AcknowledgementMode.ClientAcknowledge)]
+			AcknowledgementMode ackMode,
+			[Values(MsgDeliveryMode.Persistent, MsgDeliveryMode.NonPersistent)]
+			MsgDeliveryMode deliveryMode)
         {
             using(IConnection connection = CreateConnection(TEST_CLIENT_ID + ":" + new Random().Next()))
             {
@@ -283,13 +282,13 @@ namespace Apache.NMS.Stomp.Test
             }
         }
 
-        [RowTest]
-        [Row(AcknowledgementMode.AutoAcknowledge, MsgDeliveryMode.Persistent)]
-        [Row(AcknowledgementMode.AutoAcknowledge, MsgDeliveryMode.NonPersistent)]
-        [Row(AcknowledgementMode.ClientAcknowledge, MsgDeliveryMode.Persistent)]
-        [Row(AcknowledgementMode.ClientAcknowledge, MsgDeliveryMode.NonPersistent)]
-        public void TestReceiveCommitNonTransaction(AcknowledgementMode ackMode, MsgDeliveryMode deliveryMode)
-        {
+        [Test]
+        public void TestReceiveCommitNonTransaction(
+			[Values(AcknowledgementMode.AutoAcknowledge, AcknowledgementMode.ClientAcknowledge)]
+			AcknowledgementMode ackMode,
+			[Values(MsgDeliveryMode.Persistent, MsgDeliveryMode.NonPersistent)]
+			MsgDeliveryMode deliveryMode)
+		{
             using(IConnection connection = CreateConnection(TEST_CLIENT_ID + ":" + new Random().Next()))
             {
                 connection.Start();
@@ -326,12 +325,12 @@ namespace Apache.NMS.Stomp.Test
             }
         }
 
-        [RowTest]
-        [Row(AcknowledgementMode.AutoAcknowledge, MsgDeliveryMode.Persistent)]
-        [Row(AcknowledgementMode.AutoAcknowledge, MsgDeliveryMode.NonPersistent)]
-        [Row(AcknowledgementMode.ClientAcknowledge, MsgDeliveryMode.Persistent)]
-        [Row(AcknowledgementMode.ClientAcknowledge, MsgDeliveryMode.NonPersistent)]
-        public void TestReceiveRollbackNonTransaction(AcknowledgementMode ackMode, MsgDeliveryMode deliveryMode)
+        [Test]
+        public void TestReceiveRollbackNonTransaction(
+			[Values(AcknowledgementMode.AutoAcknowledge, AcknowledgementMode.ClientAcknowledge)]
+			AcknowledgementMode ackMode,
+			[Values(MsgDeliveryMode.Persistent, MsgDeliveryMode.NonPersistent)]
+			MsgDeliveryMode deliveryMode)
         {
             using(IConnection connection = CreateConnection(TEST_CLIENT_ID + ":" + new Random().Next()))
             {
@@ -384,10 +383,10 @@ namespace Apache.NMS.Stomp.Test
             Assert.AreEqual(expectedTextMsg.Text, actualTextMsg.Text, message);
         }
 
-        [RowTest]
-        [Row(MsgDeliveryMode.Persistent)]
-        [Row(MsgDeliveryMode.NonPersistent)]
-        public void TestRedispatchOfRolledbackTx(MsgDeliveryMode deliveryMode)
+        [Test]
+        public void TestRedispatchOfRolledbackTx(
+			[Values(MsgDeliveryMode.Persistent, MsgDeliveryMode.NonPersistent)]
+			MsgDeliveryMode deliveryMode)
         {
             using(IConnection connection = CreateConnection(TEST_CLIENT_ID + ":" + new Random().Next()))
             {
@@ -421,10 +420,10 @@ namespace Apache.NMS.Stomp.Test
             }
         }
 
-        [RowTest]
-        [Row(MsgDeliveryMode.Persistent)]
-        [Row(MsgDeliveryMode.NonPersistent)]
-        public void TestRedispatchOfUncommittedTx(MsgDeliveryMode deliveryMode)
+        [Test]
+        public void TestRedispatchOfUncommittedTx(
+			[Values(MsgDeliveryMode.Persistent, MsgDeliveryMode.NonPersistent)]
+			MsgDeliveryMode deliveryMode)
         {
             using(IConnection connection = CreateConnection(TEST_CLIENT_ID + ":" + new Random().Next()))
             {

Modified: activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/test/csharp/Util/MessageDispatchChannelTest.cs
URL: http://svn.apache.org/viewvc/activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/test/csharp/Util/MessageDispatchChannelTest.cs?rev=964863&r1=964862&r2=964863&view=diff
==============================================================================
--- activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/test/csharp/Util/MessageDispatchChannelTest.cs (original)
+++ activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/test/csharp/Util/MessageDispatchChannelTest.cs Fri Jul 16 17:14:12 2010
@@ -21,7 +21,6 @@ using Apache.NMS.Test;
 using Apache.NMS.Stomp.Util;
 using Apache.NMS.Stomp.Commands;
 using NUnit.Framework;
-using NUnit.Framework.Extensions;
 
 namespace Apache.NMS.Stomp.Test
 {

Modified: activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/vs2008-stomp-test.csproj
URL: http://svn.apache.org/viewvc/activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/vs2008-stomp-test.csproj?rev=964863&r1=964862&r2=964863&view=diff
==============================================================================
--- activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/vs2008-stomp-test.csproj (original)
+++ activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/vs2008-stomp-test.csproj Fri Jul 16 17:14:12 2010
@@ -1,4 +1,4 @@
-<?xml version="1.0" encoding="utf-8"?>
+<?xml version="1.0" encoding="utf-8"?>
 <Project DefaultTargets="Build" xmlns="http://schemas.microsoft.com/developer/msbuild/2003" ToolsVersion="3.5">
   <PropertyGroup>
     <Configuration Condition=" '$(Configuration)' == '' ">Debug</Configuration>
@@ -42,6 +42,7 @@
     <ErrorReport>prompt</ErrorReport>
     <WarningLevel>4</WarningLevel>
     <ConsolePause>false</ConsolePause>
+    <NoWarn>3016</NoWarn>
   </PropertyGroup>
   <PropertyGroup Condition=" '$(Configuration)|$(Platform)' == 'Release|AnyCPU' ">
     <DebugType>none</DebugType>
@@ -51,8 +52,13 @@
     <WarningLevel>4</WarningLevel>
     <ConsolePause>false</ConsolePause>
     <DefineConstants>NET,NET_2_0</DefineConstants>
+    <NoWarn>3016</NoWarn>
   </PropertyGroup>
   <ItemGroup>
+    <Reference Include="Apache.NMS.Test, Version=1.4.0.2021, Culture=neutral, PublicKeyToken=82756feee3957618, processorArchitecture=MSIL">
+      <SpecificVersion>False</SpecificVersion>
+      <HintPath>lib\Apache.NMS\net-2.0\Apache.NMS.Test.dll</HintPath>
+    </Reference>
     <Reference Include="nunit.framework, Version=2.4.8.0, Culture=neutral, PublicKeyToken=96d09a1eb7f44a77, processorArchitecture=MSIL">
       <SpecificVersion>False</SpecificVersion>
       <HintPath>lib\NUnit\net-2.0\nunit.framework.dll</HintPath>

Modified: activemq/activemq-dotnet/Apache.NMS.WCF/trunk/nant-common.xml
URL: http://svn.apache.org/viewvc/activemq/activemq-dotnet/Apache.NMS.WCF/trunk/nant-common.xml?rev=964863&r1=964862&r2=964863&view=diff
==============================================================================
--- activemq/activemq-dotnet/Apache.NMS.WCF/trunk/nant-common.xml (original)
+++ activemq/activemq-dotnet/Apache.NMS.WCF/trunk/nant-common.xml Fri Jul 16 17:14:12 2010
@@ -323,6 +323,7 @@
                 output="${build.bin.dir}/${project.name}.Test.dll" doc="${build.bin.dir}/${project.name}.Test.xml">
             <nowarn>
                 <warning number="1591" /> <!-- do not report warnings for missing XML comments -->
+                <warning number="3016" /> <!-- do not report warnings for array parameters  -->
             </nowarn>
             <sources failonempty="true">
                 <include name="src/test/csharp/**.cs" />
@@ -334,6 +335,7 @@
                 output="${build.bin.dir}/${project.name}.Test.dll" doc="${build.bin.dir}/${project.name}.Test.xml">
             <nowarn>
                 <warning number="1591" /> <!-- do not report warnings for missing XML comments -->
+                <warning number="3016" /> <!-- do not report warnings for array parameters  -->
             </nowarn>
             <sources failonempty="true">
                 <include name="src/test/csharp/**.cs" />

Modified: activemq/activemq-dotnet/Apache.NMS.WCF/trunk/nant.build
URL: http://svn.apache.org/viewvc/activemq/activemq-dotnet/Apache.NMS.WCF/trunk/nant.build?rev=964863&r1=964862&r2=964863&view=diff
==============================================================================
--- activemq/activemq-dotnet/Apache.NMS.WCF/trunk/nant.build (original)
+++ activemq/activemq-dotnet/Apache.NMS.WCF/trunk/nant.build Fri Jul 16 17:14:12 2010
@@ -30,7 +30,6 @@
 
     <!-- Repository organized as: organization/module/version/plaform/artifact, platform might be something like 'all' or 'net-2.0/release' -->
     <property name="nunit.dll" value="${basedir}/lib/NUnit/${current.build.framework}/nunit.framework.dll" dynamic="true"/>
-    <property name="nunit.extensions.dll" value="${basedir}/lib/NUnit/${current.build.framework}/nunit.framework.extensions.dll" dynamic="true"/>
     <property name="Apache.NMS.dll" value="${basedir}/lib/Apache.NMS/${current.build.framework}/Apache.NMS.dll" dynamic="true"/>
     <property name="Apache.NMS.pdb" value="${basedir}/lib/Apache.NMS/${current.build.framework}/Apache.NMS.pdb" dynamic="true"/>
     <property name="Apache.NMS.Test.dll" value="${basedir}/lib/Apache.NMS/${current.build.framework}//Apache.NMS.Test.dll" dynamic="true"/>
@@ -57,9 +56,8 @@
         <!-- Property grouping for 'vendor.nunit.org' -->
         <property name="vendor.nunit.org.name" value="NUnit"/>
         <property name="vendor.nunit.org.group" value="org.nunit"/>
-        <property name="vendor.nunit.org.version" value="2.4.8"/>
-        <property name="vendor.nunit.org.filenames"
-                    value="nunit.framework.dll,nunit.framework.extensions.dll" />
+        <property name="vendor.nunit.org.version" value="2.5.5"/>
+        <property name="vendor.nunit.org.filenames" value="nunit.framework.dll" />
     </target>
 
     <target name="dependency-init" description="Initializes build dependencies">
@@ -86,7 +84,6 @@
             <include name="${Apache.NMS.Test.dll}"/>
             <include name="${build.bin.dir}/${project.name}.dll"/>
             <include name="${nunit.dll}"/>
-            <include name="${nunit.extensions.dll}"/>
         </assemblyfileset>
 
         <fileset id="content.filenames">
@@ -97,7 +94,6 @@
             <include name="${Apache.NMS.Test.dll}"/>
             <include name="${Apache.NMS.Test.pdb}"/>
             <include name="${nunit.dll}"/>
-            <include name="${nunit.extensions.dll}"/>
         </fileset>
 
         <fileset id="install.filenames">

Modified: activemq/activemq-dotnet/Apache.NMS/trunk/nant-common.xml
URL: http://svn.apache.org/viewvc/activemq/activemq-dotnet/Apache.NMS/trunk/nant-common.xml?rev=964863&r1=964862&r2=964863&view=diff
==============================================================================
--- activemq/activemq-dotnet/Apache.NMS/trunk/nant-common.xml (original)
+++ activemq/activemq-dotnet/Apache.NMS/trunk/nant-common.xml Fri Jul 16 17:14:12 2010
@@ -323,6 +323,7 @@
                 output="${build.bin.dir}/${project.name}.Test.dll" doc="${build.bin.dir}/${project.name}.Test.xml">
             <nowarn>
                 <warning number="1591" /> <!-- do not report warnings for missing XML comments -->
+                <warning number="3016" /> <!-- do not report warnings for array parameters  -->
             </nowarn>
             <sources failonempty="true">
                 <include name="src/test/csharp/**.cs" />
@@ -334,6 +335,7 @@
                 output="${build.bin.dir}/${project.name}.Test.dll" doc="${build.bin.dir}/${project.name}.Test.xml">
             <nowarn>
                 <warning number="1591" /> <!-- do not report warnings for missing XML comments -->
+                <warning number="3016" /> <!-- do not report warnings for array parameters  -->
             </nowarn>
             <sources failonempty="true">
                 <include name="src/test/csharp/**.cs" />

Modified: activemq/activemq-dotnet/Apache.NMS/trunk/nant.build
URL: http://svn.apache.org/viewvc/activemq/activemq-dotnet/Apache.NMS/trunk/nant.build?rev=964863&r1=964862&r2=964863&view=diff
==============================================================================
--- activemq/activemq-dotnet/Apache.NMS/trunk/nant.build (original)
+++ activemq/activemq-dotnet/Apache.NMS/trunk/nant.build Fri Jul 16 17:14:12 2010
@@ -29,7 +29,6 @@
     <property name="project.description" value="Apache NMS (.Net Messaging Library): An abstract interface to Message Oriented Middleware (MOM) providers" />
     <property name="project.cls.compliant" value="true" />
     <property name="nunit.dll" value="${basedir}/lib/NUnit/${current.build.framework}/nunit.framework.dll" dynamic="true" />
-    <property name="nunit.extensions.dll" value="${basedir}/lib/NUnit/${current.build.framework}/nunit.framework.extensions.dll" dynamic="true" />
 
     <zipfileset id="src.package.contents" basedir="${basedir}">
         <include name="LICENSE.txt" />
@@ -62,8 +61,8 @@
         <!-- Property grouping for 'vendor.nunit.org' -->
         <property name="vendor.nunit.org.name" value="NUnit" />
         <property name="vendor.nunit.org.group" value="org.nunit" />
-        <property name="vendor.nunit.org.version" value="2.4.8" />
-        <property name="vendor.nunit.org.filenames" value="nunit.framework.dll,nunit.framework.extensions.dll" />
+        <property name="vendor.nunit.org.version" value="2.5.5" />
+        <property name="vendor.nunit.org.filenames" value="nunit.framework.dll" />
     </target>
 
     <target name="dependency-init" description="Initializes build dependencies">
@@ -91,7 +90,6 @@
             <include name="${current.build.framework.assembly.dir}/System.Xml.dll" />
             <include name="${build.bin.dir}/${project.name}.dll" />
             <include name="${nunit.dll}" />
-            <include name="${nunit.extensions.dll}" />
         </assemblyfileset>
 
         <fileset id="content.filenames">

Modified: activemq/activemq-dotnet/Apache.NMS/trunk/src/test/csharp/AsyncConsumeTest.cs
URL: http://svn.apache.org/viewvc/activemq/activemq-dotnet/Apache.NMS/trunk/src/test/csharp/AsyncConsumeTest.cs?rev=964863&r1=964862&r2=964863&view=diff
==============================================================================
--- activemq/activemq-dotnet/Apache.NMS/trunk/src/test/csharp/AsyncConsumeTest.cs (original)
+++ activemq/activemq-dotnet/Apache.NMS/trunk/src/test/csharp/AsyncConsumeTest.cs Fri Jul 16 17:14:12 2010
@@ -18,7 +18,6 @@
 using System.Threading;
 using Apache.NMS.Util;
 using NUnit.Framework;
-using NUnit.Framework.Extensions;
 
 namespace Apache.NMS.Test
 {
@@ -48,10 +47,10 @@ namespace Apache.NMS.Test
 			base.TearDown();
 		}
 
-		[RowTest]
-		[Row(MsgDeliveryMode.Persistent)]
-		[Row(MsgDeliveryMode.NonPersistent)]
-		public void TestAsynchronousConsume(MsgDeliveryMode deliveryMode)
+		[Test]
+		public void TestAsynchronousConsume(
+			[Values(MsgDeliveryMode.Persistent, MsgDeliveryMode.NonPersistent)]
+			MsgDeliveryMode deliveryMode)
 		{
 			using(IConnection connection = CreateConnection(TEST_CLIENT_ID))
 			{
@@ -78,10 +77,10 @@ namespace Apache.NMS.Test
 			}
 		}
 
-		[RowTest]
-		[Row(MsgDeliveryMode.Persistent)]
-		[Row(MsgDeliveryMode.NonPersistent)]
-		public void TestCreateConsumerAfterSend(MsgDeliveryMode deliveryMode)
+		[Test]
+		public void TestCreateConsumerAfterSend(
+			[Values(MsgDeliveryMode.Persistent, MsgDeliveryMode.NonPersistent)]
+			MsgDeliveryMode deliveryMode)
 		{
 			using(IConnection connection = CreateConnection(TEST_CLIENT_ID))
 			{
@@ -110,10 +109,10 @@ namespace Apache.NMS.Test
 			}
 		}
 
-		[RowTest]
-		[Row(MsgDeliveryMode.Persistent)]
-		[Row(MsgDeliveryMode.NonPersistent)]
-		public void TestCreateConsumerBeforeSendAddListenerAfterSend(MsgDeliveryMode deliveryMode)
+		[Test]
+		public void TestCreateConsumerBeforeSendAddListenerAfterSend(
+			[Values(MsgDeliveryMode.Persistent, MsgDeliveryMode.NonPersistent)]
+			MsgDeliveryMode deliveryMode)
 		{
 			using(IConnection connection = CreateConnection(TEST_CLIENT_ID))
 			{
@@ -141,10 +140,10 @@ namespace Apache.NMS.Test
 			}
 		}
 
-		[RowTest]
-		[Row(MsgDeliveryMode.Persistent)]
-		[Row(MsgDeliveryMode.NonPersistent)]
-		public void TestAsynchronousTextMessageConsume(MsgDeliveryMode deliveryMode)
+		[Test]
+		public void TestAsynchronousTextMessageConsume(
+			[Values(MsgDeliveryMode.Persistent, MsgDeliveryMode.NonPersistent)]
+			MsgDeliveryMode deliveryMode)
 		{
 			using(IConnection connection = CreateConnection(TEST_CLIENT_ID))
 			{
@@ -178,10 +177,10 @@ namespace Apache.NMS.Test
 			}
 		}
 
-		[RowTest]
-		[Row(MsgDeliveryMode.Persistent)]
-		[Row(MsgDeliveryMode.NonPersistent)]
-		public void TestTemporaryQueueAsynchronousConsume(MsgDeliveryMode deliveryMode)
+		[Test]
+		public void TestTemporaryQueueAsynchronousConsume(
+			[Values(MsgDeliveryMode.Persistent, MsgDeliveryMode.NonPersistent)]
+			MsgDeliveryMode deliveryMode)
 		{
 			using(IConnection connection = CreateConnection(TEST_CLIENT_ID))
 			{

Modified: activemq/activemq-dotnet/Apache.NMS/trunk/src/test/csharp/BytesMessageTest.cs
URL: http://svn.apache.org/viewvc/activemq/activemq-dotnet/Apache.NMS/trunk/src/test/csharp/BytesMessageTest.cs?rev=964863&r1=964862&r2=964863&view=diff
==============================================================================
--- activemq/activemq-dotnet/Apache.NMS/trunk/src/test/csharp/BytesMessageTest.cs (original)
+++ activemq/activemq-dotnet/Apache.NMS/trunk/src/test/csharp/BytesMessageTest.cs Fri Jul 16 17:14:12 2010
@@ -17,7 +17,6 @@
 
 using Apache.NMS.Util;
 using NUnit.Framework;
-using NUnit.Framework.Extensions;
 
 namespace Apache.NMS.Test
 {
@@ -28,10 +27,10 @@ namespace Apache.NMS.Test
 		protected static string TEST_CLIENT_ID = "BytesMessageClientId";
 		protected byte[] msgContent = {1, 2, 3, 4, 5, 6, 7, 8};
 
-		[RowTest]
-		[Row(MsgDeliveryMode.Persistent)]
-		[Row(MsgDeliveryMode.NonPersistent)]
-		public void SendReceiveBytesMessage(MsgDeliveryMode deliveryMode)
+		[Test]
+		public void SendReceiveBytesMessage(
+			[Values(MsgDeliveryMode.Persistent, MsgDeliveryMode.NonPersistent)]
+			MsgDeliveryMode deliveryMode)
 		{
 			using(IConnection connection = CreateConnection(TEST_CLIENT_ID))
 			{
@@ -57,10 +56,10 @@ namespace Apache.NMS.Test
 			}
 		}
 
-        [RowTest]
-        [Row(MsgDeliveryMode.Persistent)]
-        [Row(MsgDeliveryMode.NonPersistent)]
-        public void SendReceiveBytesMessageContentTest(MsgDeliveryMode deliveryMode)
+        [Test]
+        public void SendReceiveBytesMessageContentTest(
+			[Values(MsgDeliveryMode.Persistent, MsgDeliveryMode.NonPersistent)]
+			MsgDeliveryMode deliveryMode)
         {
             using(IConnection connection = CreateConnection(TEST_CLIENT_ID))
             {

Modified: activemq/activemq-dotnet/Apache.NMS/trunk/src/test/csharp/ConnectionTest.cs
URL: http://svn.apache.org/viewvc/activemq/activemq-dotnet/Apache.NMS/trunk/src/test/csharp/ConnectionTest.cs?rev=964863&r1=964862&r2=964863&view=diff
==============================================================================
--- activemq/activemq-dotnet/Apache.NMS/trunk/src/test/csharp/ConnectionTest.cs (original)
+++ activemq/activemq-dotnet/Apache.NMS/trunk/src/test/csharp/ConnectionTest.cs Fri Jul 16 17:14:12 2010
@@ -1,76 +1,75 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *     http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-
-using System;
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+using System;
 using NUnit.Framework;
-using NUnit.Framework.Extensions;
-
-namespace Apache.NMS.Test
-{
-	[TestFixture]
-	public class ConnectionTest : NMSTestSupport
-	{
-        protected static string TEST_CLIENT_ID = "ConnectionTestClientId";
-        
-        IConnection startedConnection = null;
-        IConnection stoppedConnection = null;
-        
-        [SetUp]
-        public override void SetUp()
-        {
-            base.SetUp();
-
-            startedConnection = CreateConnection(null);
-            startedConnection.Start();
-            stoppedConnection = CreateConnection(null);
-        }
-
-        [TearDown]
-        public override void TearDown()
-        {
-            startedConnection.Close();
-            stoppedConnection.Close();
-            
-            base.TearDown();            
-        }
-        
-		/// <summary>
-		/// Verify that it is possible to create multiple connections to the broker.
-		/// There was a bug in the connection factory which set the clientId member which made
-		/// it impossible to create an additional connection.
-		/// </summary>
-		[Test]
-		public void TwoConnections()
-		{
-			using(IConnection connection1 = CreateConnection(null))
-			{
-				connection1.Start();
-				using(IConnection connection2 = CreateConnection(null))
-				{
-					// with the bug present we'll get an exception in connection2.start()
-					connection2.Start();
-				}
-			}
-		}
-
-		[RowTest]
-		[Row(true)]
-		[Row(false)]
-		public void CreateAndDisposeWithConsumer(bool disposeConsumer)
+
+namespace Apache.NMS.Test
+{
+	[TestFixture]
+	public class ConnectionTest : NMSTestSupport
+	{
+        protected static string TEST_CLIENT_ID = "ConnectionTestClientId";
+        
+        IConnection startedConnection = null;
+        IConnection stoppedConnection = null;
+        
+        [SetUp]
+        public override void SetUp()
+        {
+            base.SetUp();
+
+            startedConnection = CreateConnection(null);
+            startedConnection.Start();
+            stoppedConnection = CreateConnection(null);
+        }
+
+        [TearDown]
+        public override void TearDown()
+        {
+            startedConnection.Close();
+            stoppedConnection.Close();
+            
+            base.TearDown();            
+        }
+        
+		/// <summary>
+		/// Verify that it is possible to create multiple connections to the broker.
+		/// There was a bug in the connection factory which set the clientId member which made
+		/// it impossible to create an additional connection.
+		/// </summary>
+		[Test]
+		public void TwoConnections()
+		{
+			using(IConnection connection1 = CreateConnection(null))
+			{
+				connection1.Start();
+				using(IConnection connection2 = CreateConnection(null))
+				{
+					// with the bug present we'll get an exception in connection2.start()
+					connection2.Start();
+				}
+			}
+		}
+
+		[Test]
+		public void CreateAndDisposeWithConsumer(
+			[Values(true, false)]
+			bool disposeConsumer)
 		{
 			using(IConnection connection = CreateConnection("DisposalTestConnection"))
 			{
@@ -87,13 +86,13 @@ namespace Apache.NMS.Test
 						consumer.Dispose();
 					}
 				}
-			}
+			}
 		}
 
-		[RowTest]
-		[Row(true)]
-		[Row(false)]
-		public void CreateAndDisposeWithProducer(bool disposeProducer)
+		[Test]
+		public void CreateAndDisposeWithProducer(
+			[Values(true, false)]
+			bool disposeProducer)
 		{
 			using(IConnection connection = CreateConnection("DisposalTestConnection"))
 			{
@@ -110,81 +109,81 @@ namespace Apache.NMS.Test
 						producer.Dispose();
 					}
 				}
-			}
-		}
-
-        [RowTest]
-        [Row(MsgDeliveryMode.Persistent, DestinationType.Queue)]
-        [Row(MsgDeliveryMode.Persistent, DestinationType.Topic)]
-        [Row(MsgDeliveryMode.NonPersistent, DestinationType.Queue)]        
-        [Row(MsgDeliveryMode.NonPersistent, DestinationType.Topic)]        
-        public void TestStartAfterSend(MsgDeliveryMode deliveryMode, DestinationType destinationType)
-        {
-            using(IConnection connection = CreateConnection(TEST_CLIENT_ID))
-            {            
-                ISession session = connection.CreateSession(AcknowledgementMode.AutoAcknowledge);
-                IDestination destination = CreateDestination(session, destinationType);
-                IMessageConsumer consumer = session.CreateConsumer(destination);
-        
-                // Send the messages
-                SendMessages(session, destination, deliveryMode, 1);
-        
-                // Start the conncection after the message was sent.
-                connection.Start();
-        
-                // Make sure only 1 message was delivered.
-                Assert.IsNotNull(consumer.Receive(TimeSpan.FromMilliseconds(1000)));
-                Assert.IsNull(consumer.ReceiveNoWait());
-            }
-        }
-        
-        /// <summary>
-        /// Tests if the consumer receives the messages that were sent before the
-        /// connection was started. 
-        /// </summary>
-        [Test]
-        public void TestStoppedConsumerHoldsMessagesTillStarted()
-        {
-            ISession startedSession = startedConnection.CreateSession(AcknowledgementMode.AutoAcknowledge);
-            ISession stoppedSession = stoppedConnection.CreateSession(AcknowledgementMode.AutoAcknowledge);
-    
-            // Setup the consumers.
-            ITopic topic = startedSession.GetTopic("ConnectionTestTopic");
-            IMessageConsumer startedConsumer = startedSession.CreateConsumer(topic);
-            IMessageConsumer stoppedConsumer = stoppedSession.CreateConsumer(topic);
-    
-            // Send the message.
-            IMessageProducer producer = startedSession.CreateProducer(topic);
-            ITextMessage message = startedSession.CreateTextMessage("Hello");
-            producer.Send(message);
-    
-            // Test the assertions.
-            IMessage m = startedConsumer.Receive(TimeSpan.FromMilliseconds(1000));
-            Assert.IsNotNull(m);
-    
-            m = stoppedConsumer.Receive(TimeSpan.FromMilliseconds(1000));
-            Assert.IsNull(m);
-    
-            stoppedConnection.Start();
-            m = stoppedConsumer.Receive(TimeSpan.FromMilliseconds(5000));
-            Assert.IsNotNull(m);
-    
-            startedSession.Close();
-            stoppedSession.Close();
-        }
-    
-        /// <summary>
-        /// Tests if the consumer is able to receive messages eveb when the
-        /// connecction restarts multiple times.
-        /// </summary>
-        [Test]
-        public void TestMultipleConnectionStops()
-        {
-            TestStoppedConsumerHoldsMessagesTillStarted();
-            stoppedConnection.Stop();
-            TestStoppedConsumerHoldsMessagesTillStarted();
-            stoppedConnection.Stop();
-            TestStoppedConsumerHoldsMessagesTillStarted();
-        }        
-	}
-}
+			}
+		}
+
+        [Test]
+        public void TestStartAfterSend(
+			[Values(MsgDeliveryMode.Persistent, MsgDeliveryMode.NonPersistent)]
+			MsgDeliveryMode deliveryMode,
+			[Values(DestinationType.Queue, DestinationType.Topic)]
+			DestinationType destinationType)
+        {
+            using(IConnection connection = CreateConnection(TEST_CLIENT_ID))
+            {            
+                ISession session = connection.CreateSession(AcknowledgementMode.AutoAcknowledge);
+                IDestination destination = CreateDestination(session, destinationType);
+                IMessageConsumer consumer = session.CreateConsumer(destination);
+        
+                // Send the messages
+                SendMessages(session, destination, deliveryMode, 1);
+        
+                // Start the conncection after the message was sent.
+                connection.Start();
+        
+                // Make sure only 1 message was delivered.
+                Assert.IsNotNull(consumer.Receive(TimeSpan.FromMilliseconds(1000)));
+                Assert.IsNull(consumer.ReceiveNoWait());
+            }
+        }
+        
+        /// <summary>
+        /// Tests if the consumer receives the messages that were sent before the
+        /// connection was started. 
+        /// </summary>
+        [Test]
+        public void TestStoppedConsumerHoldsMessagesTillStarted()
+        {
+            ISession startedSession = startedConnection.CreateSession(AcknowledgementMode.AutoAcknowledge);
+            ISession stoppedSession = stoppedConnection.CreateSession(AcknowledgementMode.AutoAcknowledge);
+    
+            // Setup the consumers.
+            ITopic topic = startedSession.GetTopic("ConnectionTestTopic");
+            IMessageConsumer startedConsumer = startedSession.CreateConsumer(topic);
+            IMessageConsumer stoppedConsumer = stoppedSession.CreateConsumer(topic);
+    
+            // Send the message.
+            IMessageProducer producer = startedSession.CreateProducer(topic);
+            ITextMessage message = startedSession.CreateTextMessage("Hello");
+            producer.Send(message);
+    
+            // Test the assertions.
+            IMessage m = startedConsumer.Receive(TimeSpan.FromMilliseconds(1000));
+            Assert.IsNotNull(m);
+    
+            m = stoppedConsumer.Receive(TimeSpan.FromMilliseconds(1000));
+            Assert.IsNull(m);
+    
+            stoppedConnection.Start();
+            m = stoppedConsumer.Receive(TimeSpan.FromMilliseconds(5000));
+            Assert.IsNotNull(m);
+    
+            startedSession.Close();
+            stoppedSession.Close();
+        }
+    
+        /// <summary>
+        /// Tests if the consumer is able to receive messages eveb when the
+        /// connecction restarts multiple times.
+        /// </summary>
+        [Test]
+        public void TestMultipleConnectionStops()
+        {
+            TestStoppedConsumerHoldsMessagesTillStarted();
+            stoppedConnection.Stop();
+            TestStoppedConsumerHoldsMessagesTillStarted();
+            stoppedConnection.Stop();
+            TestStoppedConsumerHoldsMessagesTillStarted();
+        }        
+	}
+}

Modified: activemq/activemq-dotnet/Apache.NMS/trunk/src/test/csharp/ConsumerTest.cs
URL: http://svn.apache.org/viewvc/activemq/activemq-dotnet/Apache.NMS/trunk/src/test/csharp/ConsumerTest.cs?rev=964863&r1=964862&r2=964863&view=diff
==============================================================================
--- activemq/activemq-dotnet/Apache.NMS/trunk/src/test/csharp/ConsumerTest.cs (original)
+++ activemq/activemq-dotnet/Apache.NMS/trunk/src/test/csharp/ConsumerTest.cs Fri Jul 16 17:14:12 2010
@@ -18,7 +18,6 @@
 using System;
 using System.Threading;
 using NUnit.Framework;
-using NUnit.Framework.Extensions;
 
 namespace Apache.NMS.Test
 {
@@ -33,12 +32,11 @@ namespace Apache.NMS.Test
 
 // The .NET CF does not have the ability to interrupt threads, so this test is impossible.
 #if !NETCF
-		[RowTest]
-		[Row(AcknowledgementMode.AutoAcknowledge)]
-		[Row(AcknowledgementMode.ClientAcknowledge)]
-		[Row(AcknowledgementMode.DupsOkAcknowledge)]
-		[Row(AcknowledgementMode.Transactional)]
-		public void TestNoTimeoutConsumer(AcknowledgementMode ackMode)
+		[Test]
+		public void TestNoTimeoutConsumer(
+			[Values(AcknowledgementMode.AutoAcknowledge, AcknowledgementMode.ClientAcknowledge,
+				AcknowledgementMode.DupsOkAcknowledge, AcknowledgementMode.Transactional)]
+			AcknowledgementMode ackMode)
 		{
 			// Launch a thread to perform IMessageConsumer.Receive().
 			// If it doesn't fail in less than three seconds, no exception was thrown.
@@ -90,12 +88,11 @@ namespace Apache.NMS.Test
 			}
 		}
 
-		[RowTest]
-		[Row(AcknowledgementMode.AutoAcknowledge)]
-		[Row(AcknowledgementMode.ClientAcknowledge)]
-		[Row(AcknowledgementMode.DupsOkAcknowledge)]
-		[Row(AcknowledgementMode.Transactional)]
-		public void TestSyncReceiveConsumerClose(AcknowledgementMode ackMode)
+		[Test]
+		public void TestSyncReceiveConsumerClose(
+			[Values(AcknowledgementMode.AutoAcknowledge, AcknowledgementMode.ClientAcknowledge,
+				AcknowledgementMode.DupsOkAcknowledge, AcknowledgementMode.Transactional)]
+			AcknowledgementMode ackMode)
 		{
 			// Launch a thread to perform IMessageConsumer.Receive().
 			// If it doesn't fail in less than three seconds, no exception was thrown.
@@ -161,12 +158,11 @@ namespace Apache.NMS.Test
             }
         }
         
-        [RowTest]
-        [Row(AcknowledgementMode.AutoAcknowledge)]
-        [Row(AcknowledgementMode.ClientAcknowledge)]
-        [Row(AcknowledgementMode.DupsOkAcknowledge)]
-        [Row(AcknowledgementMode.Transactional)]
-        public void TestDoChangeSentMessage(AcknowledgementMode ackMode)
+        [Test]
+        public void TestDoChangeSentMessage(
+			[Values(AcknowledgementMode.AutoAcknowledge, AcknowledgementMode.ClientAcknowledge,
+				AcknowledgementMode.DupsOkAcknowledge, AcknowledgementMode.Transactional)]
+			AcknowledgementMode ackMode)
         {
             using(IConnection connection = CreateConnection(TEST_CLIENT_ID))
             {
@@ -214,12 +210,11 @@ namespace Apache.NMS.Test
             }
         }
 		
-        [RowTest]
-        [Row(AcknowledgementMode.AutoAcknowledge)]
-        [Row(AcknowledgementMode.ClientAcknowledge)]
-        [Row(AcknowledgementMode.DupsOkAcknowledge)]
-        [Row(AcknowledgementMode.Transactional)]
-        public void TestConsumerReceiveBeforeMessageDispatched(AcknowledgementMode ackMode)
+        [Test]
+        public void TestConsumerReceiveBeforeMessageDispatched(
+			[Values(AcknowledgementMode.AutoAcknowledge, AcknowledgementMode.ClientAcknowledge,
+				AcknowledgementMode.DupsOkAcknowledge, AcknowledgementMode.Transactional)]
+			AcknowledgementMode ackMode)
         {
             // Launch a thread to perform a delayed send.
             Thread sendThread = new Thread(DelayedProducerThreadProc);
@@ -245,10 +240,12 @@ namespace Apache.NMS.Test
             }
         }
 
-        [RowTest]
-        [Row(MsgDeliveryMode.NonPersistent, DestinationType.Queue)]        
-        [Row(MsgDeliveryMode.NonPersistent, DestinationType.Topic)]             
-        public void TestDontStart(MsgDeliveryMode deliveryMode, DestinationType destinationType )
+        [Test]
+        public void TestDontStart(
+			[Values(MsgDeliveryMode.NonPersistent)]
+			MsgDeliveryMode deliveryMode,
+			[Values(DestinationType.Queue, DestinationType.Topic)]
+			DestinationType destinationType )
         {
             using(IConnection connection = CreateConnection(TEST_CLIENT_ID))
             {
@@ -264,16 +261,12 @@ namespace Apache.NMS.Test
             }
         }
 
-        [RowTest]
-        [Row(MsgDeliveryMode.NonPersistent, DestinationType.Queue)]        
-        [Row(MsgDeliveryMode.Persistent, DestinationType.Queue)]        
-        [Row(MsgDeliveryMode.NonPersistent, DestinationType.Topic)]            
-        [Row(MsgDeliveryMode.Persistent, DestinationType.Topic)]            
-        [Row(MsgDeliveryMode.NonPersistent, DestinationType.TemporaryQueue)]        
-        [Row(MsgDeliveryMode.Persistent, DestinationType.TemporaryQueue)]        
-        [Row(MsgDeliveryMode.NonPersistent, DestinationType.TemporaryTopic)]            
-        [Row(MsgDeliveryMode.Persistent, DestinationType.TemporaryTopic)]            
-        public void TestSendReceiveTransacted(MsgDeliveryMode deliveryMode, DestinationType destinationType) 
+        [Test]
+        public void TestSendReceiveTransacted(
+			[Values(MsgDeliveryMode.NonPersistent, MsgDeliveryMode.Persistent)]
+			MsgDeliveryMode deliveryMode,
+			[Values(DestinationType.Queue, DestinationType.Topic, DestinationType.TemporaryQueue, DestinationType.TemporaryTopic)]
+			DestinationType destinationType) 
         {
             using(IConnection connection = CreateConnection(TEST_CLIENT_ID))
             {

Modified: activemq/activemq-dotnet/Apache.NMS/trunk/src/test/csharp/DurableTest.cs
URL: http://svn.apache.org/viewvc/activemq/activemq-dotnet/Apache.NMS/trunk/src/test/csharp/DurableTest.cs?rev=964863&r1=964862&r2=964863&view=diff
==============================================================================
--- activemq/activemq-dotnet/Apache.NMS/trunk/src/test/csharp/DurableTest.cs (original)
+++ activemq/activemq-dotnet/Apache.NMS/trunk/src/test/csharp/DurableTest.cs Fri Jul 16 17:14:12 2010
@@ -19,7 +19,6 @@ using System;
 using System.Threading;
 using Apache.NMS.Util;
 using NUnit.Framework;
-using NUnit.Framework.Extensions;
 
 namespace Apache.NMS.Test
 {
@@ -32,12 +31,11 @@ namespace Apache.NMS.Test
 		protected static string CONSUMER_ID = "TestDurableConsumerConsumerId";
 		protected static string DURABLE_SELECTOR = "2 > 1";
 
-		[RowTest]
-		[Row(AcknowledgementMode.AutoAcknowledge)]
-		[Row(AcknowledgementMode.ClientAcknowledge)]
-		[Row(AcknowledgementMode.DupsOkAcknowledge)]
-		[Row(AcknowledgementMode.Transactional)]
-		public void TestSendWhileClosed(AcknowledgementMode ackMode)
+		[Test]
+		public void TestSendWhileClosed(
+			[Values(AcknowledgementMode.AutoAcknowledge, AcknowledgementMode.ClientAcknowledge,
+				AcknowledgementMode.DupsOkAcknowledge, AcknowledgementMode.Transactional)]
+			AcknowledgementMode ackMode)
 		{
 			try
 			{				
@@ -92,12 +90,11 @@ namespace Apache.NMS.Test
 			}			
 	    }		
 		
-		[RowTest]
-		[Row(AcknowledgementMode.AutoAcknowledge)]
-		[Row(AcknowledgementMode.ClientAcknowledge)]
-		[Row(AcknowledgementMode.DupsOkAcknowledge)]
-		[Row(AcknowledgementMode.Transactional)]
-		public void TestDurableConsumerSelectorChange(AcknowledgementMode ackMode)
+		[Test]
+		public void TestDurableConsumerSelectorChange(
+			[Values(AcknowledgementMode.AutoAcknowledge, AcknowledgementMode.ClientAcknowledge,
+				AcknowledgementMode.DupsOkAcknowledge, AcknowledgementMode.Transactional)]
+			AcknowledgementMode ackMode)
 		{
 			try
 			{
@@ -172,12 +169,11 @@ namespace Apache.NMS.Test
 			}
 		}
 
-		[RowTest]
-		[Row(AcknowledgementMode.AutoAcknowledge)]
-		[Row(AcknowledgementMode.ClientAcknowledge)]
-		[Row(AcknowledgementMode.DupsOkAcknowledge)]
-		[Row(AcknowledgementMode.Transactional)]
-		public void TestDurableConsumer(AcknowledgementMode ackMode)
+		[Test]
+		public void TestDurableConsumer(
+			[Values(AcknowledgementMode.AutoAcknowledge, AcknowledgementMode.ClientAcknowledge,
+				AcknowledgementMode.DupsOkAcknowledge, AcknowledgementMode.Transactional)]
+			AcknowledgementMode ackMode)
 		{
 			try
 			{

Modified: activemq/activemq-dotnet/Apache.NMS/trunk/src/test/csharp/MapMessageTest.cs
URL: http://svn.apache.org/viewvc/activemq/activemq-dotnet/Apache.NMS/trunk/src/test/csharp/MapMessageTest.cs?rev=964863&r1=964862&r2=964863&view=diff
==============================================================================
--- activemq/activemq-dotnet/Apache.NMS/trunk/src/test/csharp/MapMessageTest.cs (original)
+++ activemq/activemq-dotnet/Apache.NMS/trunk/src/test/csharp/MapMessageTest.cs Fri Jul 16 17:14:12 2010
@@ -19,7 +19,6 @@ using System;
 using System.Collections;
 using Apache.NMS.Util;
 using NUnit.Framework;
-using NUnit.Framework.Extensions;
 
 namespace Apache.NMS.Test
 {
@@ -45,10 +44,10 @@ namespace Apache.NMS.Test
 		protected double n = 2.3;
 		protected byte[] o = {1, 2, 3, 4, 5};
 
-		[RowTest]
-		[Row(MsgDeliveryMode.Persistent)]
-		[Row(MsgDeliveryMode.NonPersistent)]
-		public void SendReceiveMapMessage(MsgDeliveryMode deliveryMode)
+		[Test]
+		public void SendReceiveMapMessage(
+			[Values(MsgDeliveryMode.Persistent, MsgDeliveryMode.NonPersistent)]
+			MsgDeliveryMode deliveryMode)
 		{
 			using(IConnection connection = CreateConnection(TEST_CLIENT_ID))
 			{
@@ -123,10 +122,10 @@ namespace Apache.NMS.Test
 			}
 		}
 
-		[RowTest]
-		[Row(MsgDeliveryMode.Persistent)]
-		[Row(MsgDeliveryMode.NonPersistent)]
-		public void SendReceiveNestedMapMessage(MsgDeliveryMode deliveryMode)
+		[Test]
+		public void SendReceiveNestedMapMessage(
+			[Values(MsgDeliveryMode.Persistent, MsgDeliveryMode.NonPersistent)]
+			MsgDeliveryMode deliveryMode)
 		{
 			using(IConnection connection = CreateConnection(TEST_CLIENT_ID))
 			{

Modified: activemq/activemq-dotnet/Apache.NMS/trunk/src/test/csharp/MessageSelectorTest.cs
URL: http://svn.apache.org/viewvc/activemq/activemq-dotnet/Apache.NMS/trunk/src/test/csharp/MessageSelectorTest.cs?rev=964863&r1=964862&r2=964863&view=diff
==============================================================================
--- activemq/activemq-dotnet/Apache.NMS/trunk/src/test/csharp/MessageSelectorTest.cs (original)
+++ activemq/activemq-dotnet/Apache.NMS/trunk/src/test/csharp/MessageSelectorTest.cs Fri Jul 16 17:14:12 2010
@@ -19,7 +19,6 @@ using System;
 using System.Threading;
 using Apache.NMS.Util;
 using NUnit.Framework;
-using NUnit.Framework.Extensions;
 
 namespace Apache.NMS.Test
 {
@@ -36,12 +35,12 @@ namespace Apache.NMS.Test
 		private int receivedNonIgnoredMsgCount = 0;
 		private int receivedIgnoredMsgCount = 0;
 
-		[RowTest]
-		[Row(MsgDeliveryMode.Persistent, QUEUE_DESTINATION_NAME)]
-		[Row(MsgDeliveryMode.NonPersistent, QUEUE_DESTINATION_NAME)]
-		[Row(MsgDeliveryMode.Persistent, TOPIC_DESTINATION_NAME)]
-		[Row(MsgDeliveryMode.NonPersistent, TOPIC_DESTINATION_NAME)]
-		public void FilterIgnoredMessagesTest(MsgDeliveryMode deliveryMode, string destinationName)
+		[Test]
+		public void FilterIgnoredMessagesTest(
+			[Values(MsgDeliveryMode.Persistent, MsgDeliveryMode.NonPersistent)]
+			MsgDeliveryMode deliveryMode,
+			[Values(QUEUE_DESTINATION_NAME, TOPIC_DESTINATION_NAME)]
+			string destinationName)
 		{
 			using(IConnection connection1 = CreateConnection(TEST_CLIENT_ID))
 			using(IConnection connection2 = CreateConnection(TEST_CLIENT_ID2))

Modified: activemq/activemq-dotnet/Apache.NMS/trunk/src/test/csharp/MessageTest.cs
URL: http://svn.apache.org/viewvc/activemq/activemq-dotnet/Apache.NMS/trunk/src/test/csharp/MessageTest.cs?rev=964863&r1=964862&r2=964863&view=diff
==============================================================================
--- activemq/activemq-dotnet/Apache.NMS/trunk/src/test/csharp/MessageTest.cs (original)
+++ activemq/activemq-dotnet/Apache.NMS/trunk/src/test/csharp/MessageTest.cs Fri Jul 16 17:14:12 2010
@@ -17,7 +17,6 @@
 
 using Apache.NMS.Util;
 using NUnit.Framework;
-using NUnit.Framework.Extensions;
 
 namespace Apache.NMS.Test
 {
@@ -43,10 +42,10 @@ namespace Apache.NMS.Test
 		protected double	n = 2.3;
 		protected byte[]    o = {1, 2, 3, 4, 5};
 
-		[RowTest]
-		[Row(MsgDeliveryMode.Persistent)]
-		[Row(MsgDeliveryMode.NonPersistent)]
-		public void SendReceiveMessageProperties(MsgDeliveryMode deliveryMode)
+		[Test]
+		public void SendReceiveMessageProperties(
+			[Values(MsgDeliveryMode.Persistent, MsgDeliveryMode.NonPersistent)]
+			MsgDeliveryMode deliveryMode)
 		{
 			using(IConnection connection = CreateConnection(TEST_CLIENT_ID))
 			{

Modified: activemq/activemq-dotnet/Apache.NMS/trunk/src/test/csharp/NMSPropertyTest.cs
URL: http://svn.apache.org/viewvc/activemq/activemq-dotnet/Apache.NMS/trunk/src/test/csharp/NMSPropertyTest.cs?rev=964863&r1=964862&r2=964863&view=diff
==============================================================================
--- activemq/activemq-dotnet/Apache.NMS/trunk/src/test/csharp/NMSPropertyTest.cs (original)
+++ activemq/activemq-dotnet/Apache.NMS/trunk/src/test/csharp/NMSPropertyTest.cs Fri Jul 16 17:14:12 2010
@@ -18,7 +18,6 @@
 using System;
 using Apache.NMS.Util;
 using NUnit.Framework;
-using NUnit.Framework.Extensions;
 
 namespace Apache.NMS.Test
 {
@@ -36,10 +35,10 @@ namespace Apache.NMS.Test
 		protected String groupID = "BarGroup";
 		protected int groupSeq = 1;
 
-		[RowTest]
-		[Row(MsgDeliveryMode.Persistent)]
-		[Row(MsgDeliveryMode.NonPersistent)]
-		public void SendReceiveNMSProperties(MsgDeliveryMode deliveryMode)
+		[Test]
+		public void SendReceiveNMSProperties(
+			[Values(MsgDeliveryMode.Persistent, MsgDeliveryMode.NonPersistent)]
+			MsgDeliveryMode deliveryMode)
 		{
 			using(IConnection connection = CreateConnection(TEST_CLIENT_ID))
 			{

Modified: activemq/activemq-dotnet/Apache.NMS/trunk/src/test/csharp/StreamMessageTest.cs
URL: http://svn.apache.org/viewvc/activemq/activemq-dotnet/Apache.NMS/trunk/src/test/csharp/StreamMessageTest.cs?rev=964863&r1=964862&r2=964863&view=diff
==============================================================================
--- activemq/activemq-dotnet/Apache.NMS/trunk/src/test/csharp/StreamMessageTest.cs (original)
+++ activemq/activemq-dotnet/Apache.NMS/trunk/src/test/csharp/StreamMessageTest.cs Fri Jul 16 17:14:12 2010
@@ -17,7 +17,6 @@
 
 using Apache.NMS.Util;
 using NUnit.Framework;
-using NUnit.Framework.Extensions;
 
 namespace Apache.NMS.Test
 {
@@ -42,10 +41,10 @@ namespace Apache.NMS.Test
         protected float m = 2.1F;
         protected double n = 2.3;
 
-        [RowTest]
-        [Row(MsgDeliveryMode.Persistent)]
-        [Row(MsgDeliveryMode.NonPersistent)]
-        public void SendReceiveStreamMessage(MsgDeliveryMode deliveryMode)
+        [Test]
+        public void SendReceiveStreamMessage(
+			[Values(MsgDeliveryMode.Persistent, MsgDeliveryMode.NonPersistent)]
+			MsgDeliveryMode deliveryMode)
         {
             using(IConnection connection = CreateConnection(TEST_CLIENT_ID))
             {

Modified: activemq/activemq-dotnet/Apache.NMS/trunk/src/test/csharp/TempDestinationDeletionTest.cs
URL: http://svn.apache.org/viewvc/activemq/activemq-dotnet/Apache.NMS/trunk/src/test/csharp/TempDestinationDeletionTest.cs?rev=964863&r1=964862&r2=964863&view=diff
==============================================================================
--- activemq/activemq-dotnet/Apache.NMS/trunk/src/test/csharp/TempDestinationDeletionTest.cs (original)
+++ activemq/activemq-dotnet/Apache.NMS/trunk/src/test/csharp/TempDestinationDeletionTest.cs Fri Jul 16 17:14:12 2010
@@ -17,7 +17,6 @@
 
 using Apache.NMS.Util;
 using NUnit.Framework;
-using NUnit.Framework.Extensions;
 
 namespace Apache.NMS.Test
 {
@@ -30,17 +29,12 @@ namespace Apache.NMS.Test
 		protected const string TEMP_TOPIC_DESTINATION_NAME = "temp-topic://AutoDeleteTempTopic";
 		protected const string TEST_CLIENT_ID = "TempDestinationClientId";
 
-		[RowTest]
-		[Row(MsgDeliveryMode.Persistent, QUEUE_DESTINATION_NAME)]
-		[Row(MsgDeliveryMode.NonPersistent, QUEUE_DESTINATION_NAME)]
-		[Row(MsgDeliveryMode.Persistent, TOPIC_DESTINATION_NAME)]
-		[Row(MsgDeliveryMode.NonPersistent, TOPIC_DESTINATION_NAME)]
-
-		[Row(MsgDeliveryMode.Persistent, TEMP_QUEUE_DESTINATION_NAME)]
-		[Row(MsgDeliveryMode.NonPersistent, TEMP_QUEUE_DESTINATION_NAME)]
-		[Row(MsgDeliveryMode.Persistent, TEMP_TOPIC_DESTINATION_NAME)]
-		[Row(MsgDeliveryMode.NonPersistent, TEMP_TOPIC_DESTINATION_NAME)]
-		public void TempDestinationDeletionTest(MsgDeliveryMode deliveryMode, string destinationName)
+		[Test]
+		public void TempDestinationDeletionTest(
+			[Values(MsgDeliveryMode.Persistent, MsgDeliveryMode.NonPersistent)]
+			MsgDeliveryMode deliveryMode,
+			[Values(QUEUE_DESTINATION_NAME, TOPIC_DESTINATION_NAME, TEMP_QUEUE_DESTINATION_NAME, TEMP_TOPIC_DESTINATION_NAME)]
+			string destinationName)
 		{
 			using(IConnection connection1 = CreateConnection(TEST_CLIENT_ID))
 			{

Modified: activemq/activemq-dotnet/Apache.NMS/trunk/src/test/csharp/TextMessage.cs
URL: http://svn.apache.org/viewvc/activemq/activemq-dotnet/Apache.NMS/trunk/src/test/csharp/TextMessage.cs?rev=964863&r1=964862&r2=964863&view=diff
==============================================================================
--- activemq/activemq-dotnet/Apache.NMS/trunk/src/test/csharp/TextMessage.cs (original)
+++ activemq/activemq-dotnet/Apache.NMS/trunk/src/test/csharp/TextMessage.cs Fri Jul 16 17:14:12 2010
@@ -17,7 +17,6 @@
 
 using Apache.NMS.Util;
 using NUnit.Framework;
-using NUnit.Framework.Extensions;
 
 namespace Apache.NMS.Test
 {
@@ -27,10 +26,10 @@ namespace Apache.NMS.Test
 		protected static string DESTINATION_NAME = "TextMessageDestination";
 		protected static string TEST_CLIENT_ID = "TextMessageClientId";
 
-		[RowTest]
-		[Row(MsgDeliveryMode.Persistent)]
-		[Row(MsgDeliveryMode.NonPersistent)]
-		public void SendReceiveTextMessage(MsgDeliveryMode deliveryMode)
+		[Test]
+		public void SendReceiveTextMessage(
+			[Values(MsgDeliveryMode.Persistent, MsgDeliveryMode.NonPersistent)]
+			MsgDeliveryMode deliveryMode)
 		{
 			using(IConnection connection = CreateConnection(TEST_CLIENT_ID))
 			{

Modified: activemq/activemq-dotnet/Apache.NMS/trunk/src/test/csharp/TransactionTest.cs
URL: http://svn.apache.org/viewvc/activemq/activemq-dotnet/Apache.NMS/trunk/src/test/csharp/TransactionTest.cs?rev=964863&r1=964862&r2=964863&view=diff
==============================================================================
--- activemq/activemq-dotnet/Apache.NMS/trunk/src/test/csharp/TransactionTest.cs (original)
+++ activemq/activemq-dotnet/Apache.NMS/trunk/src/test/csharp/TransactionTest.cs Fri Jul 16 17:14:12 2010
@@ -18,7 +18,6 @@
 using System;
 using Apache.NMS.Util;
 using NUnit.Framework;
-using NUnit.Framework.Extensions;
 
 namespace Apache.NMS.Test
 {
@@ -29,10 +28,10 @@ namespace Apache.NMS.Test
         protected static string TEST_CLIENT_ID = "TransactionTestClientId";
         protected static string TEST_CLIENT_ID2 = "TransactionTestClientId2";
 
-        [RowTest]
-        [Row(MsgDeliveryMode.Persistent)]
-        [Row(MsgDeliveryMode.NonPersistent)]
-        public void TestSendRollback(MsgDeliveryMode deliveryMode)
+        [Test]
+        public void TestSendRollback(
+			[Values(MsgDeliveryMode.Persistent, MsgDeliveryMode.NonPersistent)]
+			MsgDeliveryMode deliveryMode)
         {
             using(IConnection connection = CreateConnection(TEST_CLIENT_ID))
             {
@@ -72,10 +71,10 @@ namespace Apache.NMS.Test
             }
         }
 
-        [RowTest]
-        [Row(MsgDeliveryMode.Persistent)]
-        [Row(MsgDeliveryMode.NonPersistent)]
-        public void TestSendSessionClose(MsgDeliveryMode deliveryMode)
+        [Test]
+        public void TestSendSessionClose(
+			[Values(MsgDeliveryMode.Persistent, MsgDeliveryMode.NonPersistent)]
+			MsgDeliveryMode deliveryMode)
         {
             ITextMessage firstMsgSend;
             ITextMessage secondMsgSend;
@@ -143,10 +142,10 @@ namespace Apache.NMS.Test
             }
         }
 
-        [RowTest]
-        [Row(MsgDeliveryMode.Persistent)]
-        [Row(MsgDeliveryMode.NonPersistent)]
-        public void TestReceiveRollback(MsgDeliveryMode deliveryMode)
+        [Test]
+        public void TestReceiveRollback(
+			[Values(MsgDeliveryMode.Persistent, MsgDeliveryMode.NonPersistent)]
+			MsgDeliveryMode deliveryMode)
         {
             using(IConnection connection = CreateConnection(TEST_CLIENT_ID))
             {
@@ -186,10 +185,10 @@ namespace Apache.NMS.Test
         }
 
 
-        [RowTest]
-        [Row(MsgDeliveryMode.Persistent)]
-        [Row(MsgDeliveryMode.NonPersistent)]
-        public void TestReceiveTwoThenRollback(MsgDeliveryMode deliveryMode)
+        [Test]
+        public void TestReceiveTwoThenRollback(
+			[Values(MsgDeliveryMode.Persistent, MsgDeliveryMode.NonPersistent)]
+			MsgDeliveryMode deliveryMode)
         {
             using(IConnection connection = CreateConnection(TEST_CLIENT_ID))
             {
@@ -230,12 +229,12 @@ namespace Apache.NMS.Test
             }
         }
 
-        [RowTest]
-        [Row(AcknowledgementMode.AutoAcknowledge, MsgDeliveryMode.Persistent)]
-        [Row(AcknowledgementMode.AutoAcknowledge, MsgDeliveryMode.NonPersistent)]
-        [Row(AcknowledgementMode.ClientAcknowledge, MsgDeliveryMode.Persistent)]
-        [Row(AcknowledgementMode.ClientAcknowledge, MsgDeliveryMode.NonPersistent)]
-        public void TestSendCommitNonTransaction(AcknowledgementMode ackMode, MsgDeliveryMode deliveryMode)
+        [Test]
+        public void TestSendCommitNonTransaction(
+			[Values(AcknowledgementMode.AutoAcknowledge, AcknowledgementMode.ClientAcknowledge)]
+			AcknowledgementMode ackMode,
+			[Values(MsgDeliveryMode.Persistent, MsgDeliveryMode.NonPersistent)]
+			MsgDeliveryMode deliveryMode)
         {
             using(IConnection connection = CreateConnection(TEST_CLIENT_ID))
             {
@@ -263,13 +262,13 @@ namespace Apache.NMS.Test
             }
         }
 
-        [RowTest]
-        [Row(AcknowledgementMode.AutoAcknowledge, MsgDeliveryMode.Persistent)]
-        [Row(AcknowledgementMode.AutoAcknowledge, MsgDeliveryMode.NonPersistent)]
-        [Row(AcknowledgementMode.ClientAcknowledge, MsgDeliveryMode.Persistent)]
-        [Row(AcknowledgementMode.ClientAcknowledge, MsgDeliveryMode.NonPersistent)]
-        public void TestReceiveCommitNonTransaction(AcknowledgementMode ackMode, MsgDeliveryMode deliveryMode)
-        {
+        [Test]
+        public void TestReceiveCommitNonTransaction(
+			[Values(AcknowledgementMode.AutoAcknowledge, AcknowledgementMode.ClientAcknowledge)]
+			AcknowledgementMode ackMode,
+			[Values(MsgDeliveryMode.Persistent, MsgDeliveryMode.NonPersistent)]
+			MsgDeliveryMode deliveryMode)
+		{
             using(IConnection connection = CreateConnection(TEST_CLIENT_ID))
             {
                 connection.Start();
@@ -306,13 +305,13 @@ namespace Apache.NMS.Test
             }
         }
 
-        [RowTest]
-        [Row(AcknowledgementMode.AutoAcknowledge, MsgDeliveryMode.Persistent)]
-        [Row(AcknowledgementMode.AutoAcknowledge, MsgDeliveryMode.NonPersistent)]
-        [Row(AcknowledgementMode.ClientAcknowledge, MsgDeliveryMode.Persistent)]
-        [Row(AcknowledgementMode.ClientAcknowledge, MsgDeliveryMode.NonPersistent)]
-        public void TestReceiveRollbackNonTransaction(AcknowledgementMode ackMode, MsgDeliveryMode deliveryMode)
-        {
+        [Test]
+        public void TestReceiveRollbackNonTransaction(
+			[Values(AcknowledgementMode.AutoAcknowledge, AcknowledgementMode.ClientAcknowledge)]
+			AcknowledgementMode ackMode,
+			[Values(MsgDeliveryMode.Persistent, MsgDeliveryMode.NonPersistent)]
+			MsgDeliveryMode deliveryMode)
+		{
             using(IConnection connection = CreateConnection(TEST_CLIENT_ID))
             {
                 connection.Start();
@@ -364,10 +363,10 @@ namespace Apache.NMS.Test
             Assert.AreEqual(expectedTextMsg.Text, actualTextMsg.Text, message);
         }
 
-        [RowTest]
-        [Row(MsgDeliveryMode.Persistent)]
-        [Row(MsgDeliveryMode.NonPersistent)]
-        public void TestRedispatchOfRolledbackTx(MsgDeliveryMode deliveryMode)
+        [Test]
+        public void TestRedispatchOfRolledbackTx(
+			[Values(MsgDeliveryMode.Persistent, MsgDeliveryMode.NonPersistent)]
+			MsgDeliveryMode deliveryMode)
         {
             using(IConnection connection = CreateConnection(TEST_CLIENT_ID))
             {
@@ -403,10 +402,10 @@ namespace Apache.NMS.Test
             }
         }
 
-        [RowTest]
-        [Row(MsgDeliveryMode.Persistent)]
-        [Row(MsgDeliveryMode.NonPersistent)]
-        public void TestRedispatchOfUncommittedTx(MsgDeliveryMode deliveryMode)
+        [Test]
+        public void TestRedispatchOfUncommittedTx(
+			[Values(MsgDeliveryMode.Persistent, MsgDeliveryMode.NonPersistent)]
+			MsgDeliveryMode deliveryMode)
         {
             using(IConnection connection = CreateConnection(TEST_CLIENT_ID))
             {

Modified: activemq/activemq-dotnet/Apache.NMS/trunk/src/test/csharp/URISupportTest.cs
URL: http://svn.apache.org/viewvc/activemq/activemq-dotnet/Apache.NMS/trunk/src/test/csharp/URISupportTest.cs?rev=964863&r1=964862&r2=964863&view=diff
==============================================================================
--- activemq/activemq-dotnet/Apache.NMS/trunk/src/test/csharp/URISupportTest.cs (original)
+++ activemq/activemq-dotnet/Apache.NMS/trunk/src/test/csharp/URISupportTest.cs Fri Jul 16 17:14:12 2010
@@ -21,7 +21,6 @@ using System.Collections.Specialized;
 using Apache.NMS.Util;
 
 using NUnit.Framework;
-using NUnit.Framework.Extensions;
 
 namespace Apache.NMS.Test
 {
@@ -33,16 +32,17 @@ namespace Apache.NMS.Test
 	        Assert.AreEqual(expected, map[key], "Map key: " + key);
 	    }
 
-        [RowTest]
-        [Row("tcp://127.0.0.1:61616")]
-        [Row("tcp:127.0.0.1:61616")]
-        [Row("failover:tcp://127.0.0.1:61616")]
-        [Row("failover:(tcp://127.0.0.1:61616)")]
-        [Row("failover://(tcp://127.0.0.1:61616)")]
-        [Row("failover://(tcp://127.0.0.1:61616,tcp:192.168.0.1:61616)")]
-        [Row("activemq:failover:(tcp://localhost:61616)")]
-        [Row("activemq:failover:(tcp://${activemqhost}:61616)")]
-        public void TestCreateSupportedUriVariations(string uriString)
+        [Test]
+        public void TestCreateSupportedUriVariations(
+            [Values("tcp://127.0.0.1:61616",
+                    "tcp:127.0.0.1:61616",
+                    "failover:tcp://127.0.0.1:61616",
+                    "failover:(tcp://127.0.0.1:61616)",
+                    "failover://(tcp://127.0.0.1:61616)",
+                    "failover://(tcp://127.0.0.1:61616,tcp:192.168.0.1:61616)",
+                    "activemq:failover:(tcp://localhost:61616)",
+                    "activemq:failover:(tcp://${activemqhost}:61616)")]
+        	string uriString)
         {
             Uri result = URISupport.CreateCompatibleUri(NMSTestSupport.ReplaceEnvVar(uriString));
 

Modified: activemq/activemq-dotnet/Apache.NMS/trunk/vs2008-nms-test.csproj
URL: http://svn.apache.org/viewvc/activemq/activemq-dotnet/Apache.NMS/trunk/vs2008-nms-test.csproj?rev=964863&r1=964862&r2=964863&view=diff
==============================================================================
--- activemq/activemq-dotnet/Apache.NMS/trunk/vs2008-nms-test.csproj (original)
+++ activemq/activemq-dotnet/Apache.NMS/trunk/vs2008-nms-test.csproj Fri Jul 16 17:14:12 2010
@@ -46,6 +46,7 @@
     <OutputPath>build\net-2.0\debug\</OutputPath>
     <DefineConstants>TRACE;DEBUG;NET,NET_2_0</DefineConstants>
     <AllowUnsafeBlocks>false</AllowUnsafeBlocks>
+    <NoWarn>3016</NoWarn>
   </PropertyGroup>
   <PropertyGroup Condition=" '$(Configuration)|$(Platform)' == 'Release|AnyCPU' ">
     <DebugSymbols>true</DebugSymbols>
@@ -54,16 +55,13 @@
     <DefineConstants>TRACE;NET,NET_2_0</DefineConstants>
     <AllowUnsafeBlocks>false</AllowUnsafeBlocks>
     <DebugType>full</DebugType>
+    <NoWarn>3016</NoWarn>
   </PropertyGroup>
   <ItemGroup>
     <Reference Include="nunit.framework, Version=2.4.8.0, Culture=neutral, PublicKeyToken=96d09a1eb7f44a77, processorArchitecture=MSIL">
       <SpecificVersion>False</SpecificVersion>
       <HintPath>lib\NUnit\net-3.5\nunit.framework.dll</HintPath>
     </Reference>
-    <Reference Include="nunit.framework.extensions, Version=2.4.8.0, Culture=neutral, PublicKeyToken=96d09a1eb7f44a77, processorArchitecture=MSIL">
-      <SpecificVersion>False</SpecificVersion>
-      <HintPath>lib\NUnit\net-3.5\nunit.framework.extensions.dll</HintPath>
-    </Reference>
     <Reference Include="System" />
     <Reference Include="System.Xml" />
   </ItemGroup>