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/09 09:19:17 UTC

svn commit: r384457 [4/4] - in /incubator/activemq/trunk: activemq-core/src/gram/script/ activemq-dotnet/ activemq-dotnet/src/main/csharp/ activemq-dotnet/src/main/csharp/ActiveMQ/Commands/ activemq-dotnet/src/main/csharp/ActiveMQ/OpenWire/ activemq-do...

Modified: incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/IBytesMessage.cs
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/IBytesMessage.cs?rev=384457&r1=384456&r2=384457&view=diff
==============================================================================
--- incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/IBytesMessage.cs (original)
+++ incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/IBytesMessage.cs Thu Mar  9 00:19:01 2006
@@ -14,15 +14,11 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-using NMS;
-
-
-
-/// <summary>
-/// Represents a binary based message
-/// </summary>
 namespace NMS
 {
+	/// <summary>
+	/// Represents a binary based message
+	/// </summary>
 	public interface IBytesMessage : IMessage
     {
         

Modified: incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/IConnection.cs
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/IConnection.cs?rev=384457&r1=384456&r2=384457&view=diff
==============================================================================
--- incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/IConnection.cs (original)
+++ incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/IConnection.cs Thu Mar  9 00:19:01 2006
@@ -14,24 +14,17 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-using NMS;
-using System;
-
-
 namespace NMS
 {
 	public enum AcknowledgementMode
     {
         Unknown, AutoAcknowledge, ClientAcknowledge, Transactional
     }
-}
-
-/// <summary>
-/// Represents a connection with a message broker
-/// </summary>
-namespace NMS
-{
-	public interface IConnection : IDisposable, IStartable, IStoppable
+	
+	/// <summary>
+	/// Represents a connection with a message broker
+	/// </summary>
+	public interface IConnection : System.IDisposable, IStartable, IStoppable
     {
         
         /// <summary>
@@ -53,7 +46,7 @@
             set;
         }
         
-        String ClientId
+        string ClientId
         {
             get;
             set;

Modified: incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/IConnectionFactory.cs
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/IConnectionFactory.cs?rev=384457&r1=384456&r2=384457&view=diff
==============================================================================
--- incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/IConnectionFactory.cs (original)
+++ incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/IConnectionFactory.cs Thu Mar  9 00:19:01 2006
@@ -14,15 +14,12 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-using NMS;
-
-
-
-/// <summary>
-/// A Factory of IConnection objects
-/// </summary>
 namespace NMS
 {
+	
+	/// <summary>
+	/// A Factory of IConnection objects
+	/// </summary>
 	public interface IConnectionFactory
 	{
 		

Modified: incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/IDestination.cs
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/IDestination.cs?rev=384457&r1=384456&r2=384457&view=diff
==============================================================================
--- incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/IDestination.cs (original)
+++ incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/IDestination.cs Thu Mar  9 00:19:01 2006
@@ -14,16 +14,16 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-
-
-/// <summary>
-/// Summary description for Destination.
-/// </summary>
 namespace NMS
 {
+	
+	/// <summary>
+	/// Summary description for Destination.
+	/// </summary>
 	public interface IDestination
 	{
 	}
+	
 }
 
 

Modified: incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/IMapMessage.cs
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/IMapMessage.cs?rev=384457&r1=384456&r2=384457&view=diff
==============================================================================
--- incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/IMapMessage.cs (original)
+++ incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/IMapMessage.cs Thu Mar  9 00:19:01 2006
@@ -14,16 +14,13 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-using NMS;
-
-
-
-/// <summary>
-/// Represents a Map message which contains key and value pairs which are
-/// of primitive types
-/// </summary>
 namespace NMS
 {
+	
+	/// <summary>
+	/// Represents a Map message which contains key and value pairs which are
+	/// of primitive types
+	/// </summary>
 	public interface IMapMessage : IMessage
     {
         IPrimitiveMap Body

Modified: incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/IMessage.cs
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/IMessage.cs?rev=384457&r1=384456&r2=384457&view=diff
==============================================================================
--- incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/IMessage.cs (original)
+++ incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/IMessage.cs Thu Mar  9 00:19:01 2006
@@ -14,15 +14,11 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-using NMS;
-
-
-
-/// <summary>
-/// Represents a message either to be sent to a message broker or received from a message broker
-/// </summary>
 namespace NMS
 {
+	/// <summary>
+	/// Represents a message either to be sent to a message broker or received from a message broker
+	/// </summary>
 	public interface IMessage
     {
         

Modified: incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/IMessageConsumer.cs
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/IMessageConsumer.cs?rev=384457&r1=384456&r2=384457&view=diff
==============================================================================
--- incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/IMessageConsumer.cs (original)
+++ incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/IMessageConsumer.cs Thu Mar  9 00:19:01 2006
@@ -14,21 +14,17 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-using NMS;
-using System;
-
-
 namespace NMS
 {
+	/// <summary>
+	/// A delegate that can receive messages async.
+	/// </summary>
 	public delegate void MessageListener(IMessage message);
-}
 
-/// <summary>
-/// A consumer of messages
-/// </summary>
-namespace NMS
-{
-	public interface IMessageConsumer : IDisposable
+	/// <summary>
+	/// A consumer of messages
+	/// </summary>
+	public interface IMessageConsumer : System.IDisposable
     {
         
         /// <summary>

Modified: incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/IMessageProducer.cs
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/IMessageProducer.cs?rev=384457&r1=384456&r2=384457&view=diff
==============================================================================
--- incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/IMessageProducer.cs (original)
+++ incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/IMessageProducer.cs Thu Mar  9 00:19:01 2006
@@ -14,17 +14,13 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-using NMS;
-using System;
-
-
-
-/// <summary>
-/// An object capable of sending messages to some destination
-/// </summary>
 namespace NMS
 {
-	public interface IMessageProducer : IDisposable
+	
+	/// <summary>
+	/// An object capable of sending messages to some destination
+	/// </summary>
+	public interface IMessageProducer : System.IDisposable
 	{
 		
         /// <summary>

Modified: incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/IPrimitiveMap.cs
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/IPrimitiveMap.cs?rev=384457&r1=384456&r2=384457&view=diff
==============================================================================
--- incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/IPrimitiveMap.cs (original)
+++ incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/IPrimitiveMap.cs Thu Mar  9 00:19:01 2006
@@ -14,16 +14,13 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-using System.Collections;
-
-
-
-/// <summary>
-/// Represents a Map of primitive types where the keys are all string instances
-/// and the values are strings or numbers.
-/// </summary>
 namespace NMS
 {
+	
+	/// <summary>
+	/// Represents a Map of primitive types where the keys are all string instances
+	/// and the values are strings or numbers.
+	/// </summary>
 	public interface IPrimitiveMap
     {
         
@@ -38,12 +35,12 @@
             get;
         }
         
-        ICollection Keys
+        System.Collections.ICollection Keys
         {
             get;
         }
         
-        ICollection Values
+        System.Collections.ICollection Values
         {
             get;
         }

Modified: incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/IQueue.cs
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/IQueue.cs?rev=384457&r1=384456&r2=384457&view=diff
==============================================================================
--- incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/IQueue.cs (original)
+++ incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/IQueue.cs Thu Mar  9 00:19:01 2006
@@ -14,20 +14,15 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-using NMS;
-using System;
-
-
-
-/// <summary>
-/// Summary description for IQueue.
-/// </summary>
 namespace NMS
 {
+	/// <summary>
+	/// Summary description for IQueue.
+	/// </summary>
 	public interface IQueue : IDestination
 	{
 		
-		String QueueName
+		string QueueName
 		{
 			get;
 		}

Modified: incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/ISession.cs
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/ISession.cs?rev=384457&r1=384456&r2=384457&view=diff
==============================================================================
--- incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/ISession.cs (original)
+++ incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/ISession.cs Thu Mar  9 00:19:01 2006
@@ -14,18 +14,13 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-using NMS;
-using System;
-
-
-
-/// <summary>
-/// Represents a single unit of work on an IConnection.
-/// So the ISession can be used to perform transactional receive and sends
-/// </summary>
 namespace NMS
 {
-	public interface ISession : IDisposable
+	/// <summary>
+	/// Represents a single unit of work on an IConnection.
+	/// So the ISession can be used to perform transactional receive and sends
+	/// </summary>
+	public interface ISession : System.IDisposable
     {
         
         /// <summary>

Modified: incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/IStartable.cs
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/IStartable.cs?rev=384457&r1=384456&r2=384457&view=diff
==============================================================================
--- incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/IStartable.cs (original)
+++ incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/IStartable.cs Thu Mar  9 00:19:01 2006
@@ -14,10 +14,11 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-
-
 namespace NMS
 {
+	/// <summary>
+	/// Implemented by NMS objects that can be started.
+	/// </summary>
 	public interface IStartable
     {
         void Start();

Modified: incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/IStoppable.cs
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/IStoppable.cs?rev=384457&r1=384456&r2=384457&view=diff
==============================================================================
--- incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/IStoppable.cs (original)
+++ incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/IStoppable.cs Thu Mar  9 00:19:01 2006
@@ -14,9 +14,11 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-
 namespace NMS
 {
+	/// <summary>
+	/// Implemented by NMS objects that can be started.
+	/// </summary>
 	public interface IStoppable
 	{
 		void Stop();

Modified: incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/ITemporaryQueue.cs
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/ITemporaryQueue.cs?rev=384457&r1=384456&r2=384457&view=diff
==============================================================================
--- incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/ITemporaryQueue.cs (original)
+++ incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/ITemporaryQueue.cs Thu Mar  9 00:19:01 2006
@@ -14,15 +14,11 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-using NMS;
-
-
-
-/// <summary>
-/// Summary description for ITemporaryQueue.
-/// </summary>
 namespace NMS
 {
+	/// <summary>
+	/// Summary description for ITemporaryQueue.
+	/// </summary>
 	public interface ITemporaryQueue : IDestination
 	{
 	}

Modified: incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/ITemporaryTopic.cs
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/ITemporaryTopic.cs?rev=384457&r1=384456&r2=384457&view=diff
==============================================================================
--- incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/ITemporaryTopic.cs (original)
+++ incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/ITemporaryTopic.cs Thu Mar  9 00:19:01 2006
@@ -14,15 +14,11 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-using NMS;
-
-
-
-/// <summary>
-/// Summary description for TemporaryTopic.
-/// </summary>
 namespace NMS
 {
+	/// <summary>
+	/// Summary description for TemporaryTopic.
+	/// </summary>
 	public interface ITemporaryTopic : IDestination
 	{
 	}

Modified: incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/ITextMessage.cs
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/ITextMessage.cs?rev=384457&r1=384456&r2=384457&view=diff
==============================================================================
--- incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/ITextMessage.cs (original)
+++ incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/ITextMessage.cs Thu Mar  9 00:19:01 2006
@@ -14,15 +14,11 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-using NMS;
-
-
-
-/// <summary>
-/// Represents a text based message
-/// </summary>
 namespace NMS
 {
+	/// <summary>
+	/// Represents a text based message
+	/// </summary>
 	public interface ITextMessage : IMessage
     {
         

Modified: incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/ITopic.cs
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/ITopic.cs?rev=384457&r1=384456&r2=384457&view=diff
==============================================================================
--- incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/ITopic.cs (original)
+++ incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/ITopic.cs Thu Mar  9 00:19:01 2006
@@ -14,20 +14,15 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-using NMS;
-using System;
-
-
-
-/// <summary>
-/// Summary description for ITopic.
-/// </summary>
 namespace NMS
 {
+	/// <summary>
+	/// Summary description for ITopic.
+	/// </summary>
 	public interface ITopic : IDestination
 	{
 		
-		String TopicName
+		string TopicName
 		{
 			get;
 		}

Added: incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/NMSConnectionException.cs
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/NMSConnectionException.cs?rev=384457&view=auto
==============================================================================
--- incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/NMSConnectionException.cs (added)
+++ incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/NMSConnectionException.cs Thu Mar  9 00:19:01 2006
@@ -0,0 +1,30 @@
+/*
+ * Copyright 2006 The Apache Software Foundation or its licensors, as
+ * applicable.
+ *
+ * Licensed 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.
+ */
+namespace NMS
+{
+	/// <summary>
+	/// Represents a connection failure.
+	/// </summary>
+	public class NMSConnectionException : NMSException
+	{
+		public NMSConnectionException(string message) : base(message)
+		{
+		}
+	}
+}
+
+

Added: incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/NMSException.cs
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/NMSException.cs?rev=384457&view=auto
==============================================================================
--- incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/NMSException.cs (added)
+++ incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/NMSException.cs Thu Mar  9 00:19:01 2006
@@ -0,0 +1,30 @@
+/*
+ * Copyright 2006 The Apache Software Foundation or its licensors, as
+ * applicable.
+ *
+ * Licensed 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.
+ */
+namespace NMS
+{
+	/// <summary>
+	/// Represents a NMS exception
+	/// </summary>
+	public class NMSException : System.Exception
+	{
+		public NMSException(string message) : base(message)
+		{
+		}
+	}
+}
+
+

Modified: incubator/activemq/trunk/activemq-dotnet/src/test/csharp/ActiveMQ/OpenWire/BooleanStreamTest.cs
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/activemq-dotnet/src/test/csharp/ActiveMQ/OpenWire/BooleanStreamTest.cs?rev=384457&r1=384456&r2=384457&view=diff
==============================================================================
--- incubator/activemq/trunk/activemq-dotnet/src/test/csharp/ActiveMQ/OpenWire/BooleanStreamTest.cs (original)
+++ incubator/activemq/trunk/activemq-dotnet/src/test/csharp/ActiveMQ/OpenWire/BooleanStreamTest.cs Thu Mar  9 00:19:01 2006
@@ -31,7 +31,7 @@
         [Test]
 		public void TestBooleanMarshallingUsingAllTrue()
 		{
-			TestBooleanStream(numberOfBytes, new GetBooleanValueDelegate(GetBooleanValueAllTrue));
+			DoTestBooleanStream(numberOfBytes, new GetBooleanValueDelegate(GetBooleanValueAllTrue));
 		}
 		public bool GetBooleanValueAllTrue(int index, int count)
 		{
@@ -41,7 +41,7 @@
         [Test]
 		public void TestBooleanMarshallingUsingAllFalse()
 		{
-			TestBooleanStream(numberOfBytes, new GetBooleanValueDelegate(GetBooleanValueAllFalse));
+			DoTestBooleanStream(numberOfBytes, new GetBooleanValueDelegate(GetBooleanValueAllFalse));
 		}
 		public bool GetBooleanValueAllFalse(int index, int count)
 		{
@@ -51,7 +51,7 @@
         [Test]
 		public void TestBooleanMarshallingUsingAlternateTrueFalse()
 		{
-			TestBooleanStream(numberOfBytes, new GetBooleanValueDelegate(GetBooleanValueAlternateTrueFalse));
+			DoTestBooleanStream(numberOfBytes, new GetBooleanValueDelegate(GetBooleanValueAlternateTrueFalse));
 		}
 		public bool GetBooleanValueAlternateTrueFalse(int index, int count)
 		{
@@ -61,14 +61,14 @@
 		[Test]
 		public void TestBooleanMarshallingUsingAlternateFalseTrue()
 		{
-			TestBooleanStream(numberOfBytes, new GetBooleanValueDelegate(GetBooleanValueAlternateFalseTrue));
+			DoTestBooleanStream(numberOfBytes, new GetBooleanValueDelegate(GetBooleanValueAlternateFalseTrue));
 		}
 		public bool GetBooleanValueAlternateFalseTrue(int index, int count)
 		{
 			return (index & 1) != 0;
 		}
 		
-		protected void TestBooleanStream(int numberOfBytes, GetBooleanValueDelegate valueDelegate)
+		protected void DoTestBooleanStream(int numberOfBytes, GetBooleanValueDelegate valueDelegate)
 		{
 			for (int i = 1017; i < numberOfBytes; i++)
 			{

Modified: incubator/activemq/trunk/activemq-dotnet/src/test/csharp/CommonAssemblyInfo.cs
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/activemq-dotnet/src/test/csharp/CommonAssemblyInfo.cs?rev=384457&r1=384456&r2=384457&view=diff
==============================================================================
--- incubator/activemq/trunk/activemq-dotnet/src/test/csharp/CommonAssemblyInfo.cs (original)
+++ incubator/activemq/trunk/activemq-dotnet/src/test/csharp/CommonAssemblyInfo.cs Thu Mar  9 00:19:01 2006
@@ -22,6 +22,6 @@
 [assembly: AssemblyCopyrightAttribute("Copyright (C) 2005-2006 Apache Software Foundation")]
 [assembly: AssemblyTrademarkAttribute("")]
 [assembly: AssemblyCultureAttribute("")]
-[assembly: AssemblyVersionAttribute("4.0.2256.0")]
+[assembly: AssemblyVersionAttribute("4.0.2259.0")]
 [assembly: AssemblyInformationalVersionAttribute("4.0")]