You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@activemq.apache.org by ta...@apache.org on 2009/12/07 20:09:57 UTC

svn commit: r888089 - in /activemq/activemq-dotnet/Apache.NMS.Stomp/trunk: ./ src/main/csharp/ src/main/csharp/Commands/ src/main/csharp/Transport/Tcp/

Author: tabish
Date: Mon Dec  7 19:09:55 2009
New Revision: 888089

URL: http://svn.apache.org/viewvc?rev=888089&view=rev
Log:
Fixing some compiler errors and bringing in more NMS Implementation for Stomp, basic structure is in place now, code compiles now.

Added:
    activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/main/csharp/BrokerException.cs   (with props)
    activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/main/csharp/Commands/ConnectionError.cs   (with props)
    activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/main/csharp/Commands/RemoveSubscriptionInfo.cs   (with props)
    activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/main/csharp/ConnectionClosedException.cs   (with props)
Modified:
    activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/main/csharp/Commands/DataStructureTypes.cs
    activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/main/csharp/MessageConsumer.cs
    activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/main/csharp/MessageProducer.cs
    activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/main/csharp/Session.cs
    activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/main/csharp/TransactionContext.cs
    activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/main/csharp/Transport/Tcp/TcpTransportFactory.cs
    activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/vs2008-stomp.csproj

Added: activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/main/csharp/BrokerException.cs
URL: http://svn.apache.org/viewvc/activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/main/csharp/BrokerException.cs?rev=888089&view=auto
==============================================================================
--- activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/main/csharp/BrokerException.cs (added)
+++ activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/main/csharp/BrokerException.cs Mon Dec  7 19:09:55 2009
@@ -0,0 +1,74 @@
+/*
+ * 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.Text;
+using Apache.NMS;
+using Apache.NMS.Stomp.Commands;
+
+namespace Apache.NMS.Stomp
+{
+
+    /// <summary>
+    /// Exception thrown when the broker returns an error
+    /// </summary>
+    public class BrokerException : NMSException
+    {
+        private BrokerError brokerError;
+
+        /// <summary>
+        /// Generates a nice textual stack trace
+        /// </summary>
+        public static string StackTraceDump(StackTraceElement[] elements)
+        {
+            StringBuilder builder = new StringBuilder();
+            if (elements != null)
+            {
+                foreach (StackTraceElement e in elements)
+                {
+                    builder.Append("\n " + e.ClassName + "." + e.MethodName + "(" + e.FileName + ":" + e.LineNumber + ")");
+                }
+            }
+            return builder.ToString();
+        }
+
+        public BrokerException() : base("Broker failed with missing exception log")
+        {
+        }
+
+        public BrokerException(BrokerError brokerError) : base(
+            brokerError.ExceptionClass + " : " + brokerError.Message + "\n" + StackTraceDump(brokerError.StackTraceElements))
+        {
+            this.brokerError = brokerError;
+        }
+
+        public BrokerError BrokerError
+        {
+            get {
+                return brokerError;
+            }
+        }
+
+        public virtual string JavaStackTrace
+        {
+            get {
+                return brokerError.StackTrace;
+            }
+        }
+
+    }
+}
+
+

Propchange: activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/main/csharp/BrokerException.cs
------------------------------------------------------------------------------
    svn:eol-style = native

Added: activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/main/csharp/Commands/ConnectionError.cs
URL: http://svn.apache.org/viewvc/activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/main/csharp/Commands/ConnectionError.cs?rev=888089&view=auto
==============================================================================
--- activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/main/csharp/Commands/ConnectionError.cs (added)
+++ activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/main/csharp/Commands/ConnectionError.cs Mon Dec  7 19:09:55 2009
@@ -0,0 +1,80 @@
+/*
+ * 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 System.Collections;
+
+namespace Apache.NMS.Stomp.Commands
+{
+    public class ConnectionError : BaseCommand
+    {
+        BrokerError exception;
+        ConnectionId connectionId;
+
+        ///
+        /// <summery>
+        ///  Get the unique identifier that this object and its own
+        ///  Marshaler share.
+        /// </summery>
+        ///
+        public override byte GetDataStructureType()
+        {
+            return DataStructureTypes.ErrorType;
+        }
+
+        ///
+        /// <summery>
+        ///  Returns a string containing the information for this DataStructure
+        ///  such as its type and value of its elements.
+        /// </summery>
+        ///
+        public override string ToString()
+        {
+            return GetType().Name + "[" + 
+                "Exception=" + Exception + 
+                "ConnectionId=" + ConnectionId + 
+                "]";
+        }
+
+        public BrokerError Exception
+        {
+            get { return exception; }
+            set { this.exception = value; }
+        }
+
+        public ConnectionId ConnectionId
+        {
+            get { return connectionId; }
+            set { this.connectionId = value; }
+        }
+
+        ///
+        /// <summery>
+        ///  Return an answer of true to the isConnectionError() query.
+        /// </summery>
+        ///
+        public override bool IsConnectionError
+        {
+            get
+            {
+                return true;
+            }
+        }
+
+    };
+}
+

Propchange: activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/main/csharp/Commands/ConnectionError.cs
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/main/csharp/Commands/DataStructureTypes.cs
URL: http://svn.apache.org/viewvc/activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/main/csharp/Commands/DataStructureTypes.cs?rev=888089&r1=888088&r2=888089&view=diff
==============================================================================
--- activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/main/csharp/Commands/DataStructureTypes.cs (original)
+++ activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/main/csharp/Commands/DataStructureTypes.cs Mon Dec  7 19:09:55 2009
@@ -47,7 +47,8 @@
         public const byte ShutdownInfoType = 23;
         public const byte ResponseType = 24;
         public const byte RemoveInfoType = 25;
-        public const byte ErrorResponseType = 26;
+        public const byte RemoveSubscriptionInfoType = 26;
+        public const byte ErrorResponseType = 27;
         
         public const byte DestinationType = 48;
         public const byte TempDestinationType = 49;

Added: activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/main/csharp/Commands/RemoveSubscriptionInfo.cs
URL: http://svn.apache.org/viewvc/activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/main/csharp/Commands/RemoveSubscriptionInfo.cs?rev=888089&view=auto
==============================================================================
--- activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/main/csharp/Commands/RemoveSubscriptionInfo.cs (added)
+++ activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/main/csharp/Commands/RemoveSubscriptionInfo.cs Mon Dec  7 19:09:55 2009
@@ -0,0 +1,97 @@
+/*
+ * 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 System.Collections;
+
+namespace Apache.NMS.Stomp.Commands
+{
+    /*
+     *
+     *  Command code for OpenWire format for RemoveSubscriptionInfo
+     *
+     *  NOTE!: This file is auto generated - do not modify!
+     *         if you need to make a change, please see the Java Classes
+     *         in the nms-activemq-openwire-generator module
+     *
+     */
+    public class RemoveSubscriptionInfo : BaseCommand
+    {
+        ConnectionId connectionId;
+        string subscriptionName;
+        string clientId;
+
+        ///
+        /// <summery>
+        ///  Get the unique identifier that this object and its own
+        ///  Marshaler share.
+        /// </summery>
+        ///
+        public override byte GetDataStructureType()
+        {
+            return DataStructureTypes.RemoveSubscriptionInfoType;
+        }
+
+        ///
+        /// <summery>
+        ///  Returns a string containing the information for this DataStructure
+        ///  such as its type and value of its elements.
+        /// </summery>
+        ///
+        public override string ToString()
+        {
+            return GetType().Name + "[" + 
+                "ConnectionId=" + ConnectionId + 
+                "SubscriptionName=" + SubscriptionName + 
+                "ClientId=" + ClientId + 
+                "]";
+        }
+
+        public ConnectionId ConnectionId
+        {
+            get { return connectionId; }
+            set { this.connectionId = value; }
+        }
+
+        public string SubscriptionName
+        {
+            get { return subscriptionName; }
+            set { this.subscriptionName = value; }
+        }
+
+        public string ClientId
+        {
+            get { return clientId; }
+            set { this.clientId = value; }
+        }
+
+        ///
+        /// <summery>
+        ///  Return an answer of true to the isRemoveSubscriptionInfo() query.
+        /// </summery>
+        ///
+        public override bool IsRemoveSubscriptionInfo
+        {
+            get
+            {
+                return true;
+            }
+        }
+
+    };
+}
+

Propchange: activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/main/csharp/Commands/RemoveSubscriptionInfo.cs
------------------------------------------------------------------------------
    svn:eol-style = native

Added: activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/main/csharp/ConnectionClosedException.cs
URL: http://svn.apache.org/viewvc/activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/main/csharp/ConnectionClosedException.cs?rev=888089&view=auto
==============================================================================
--- activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/main/csharp/ConnectionClosedException.cs (added)
+++ activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/main/csharp/ConnectionClosedException.cs Mon Dec  7 19:09:55 2009
@@ -0,0 +1,30 @@
+/*
+ * 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 Apache.NMS;
+
+namespace Apache.NMS.Stomp
+{
+    /// <summary>
+    /// Exception thrown when a connection is used that it already closed
+    /// </summary>
+    public class ConnectionClosedException : NMSException
+    {
+        public ConnectionClosedException() : base("The connection is already closed!")
+        {
+        }
+    }
+}

Propchange: activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/main/csharp/ConnectionClosedException.cs
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/main/csharp/ConnectionClosedException.cs
------------------------------------------------------------------------------
    svn:executable = *

Modified: activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/main/csharp/MessageConsumer.cs
URL: http://svn.apache.org/viewvc/activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/main/csharp/MessageConsumer.cs?rev=888089&r1=888088&r2=888089&view=diff
==============================================================================
--- activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/main/csharp/MessageConsumer.cs (original)
+++ activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/main/csharp/MessageConsumer.cs Mon Dec  7 19:09:55 2009
@@ -153,7 +153,6 @@
             CheckClosed();
             CheckMessageListener();
 
-            SendPullRequest(0);
             MessageDispatch dispatch = this.Dequeue(TimeSpan.FromMilliseconds(-1));
 
             if(dispatch == null)
@@ -164,7 +163,7 @@
             BeforeMessageIsConsumed(dispatch);
             AfterMessageIsConsumed(dispatch, false);
 
-            return CreateActiveMQMessage(dispatch);
+            return CreateStompMessage(dispatch);
         }
 
         public IMessage Receive(TimeSpan timeout)
@@ -172,17 +171,7 @@
             CheckClosed();
             CheckMessageListener();
 
-            MessageDispatch dispatch = null;
-            SendPullRequest((long) timeout.TotalMilliseconds);
-
-            if(this.PrefetchSize == 0)
-            {
-                dispatch = this.Dequeue(TimeSpan.FromMilliseconds(-1));
-            }
-            else
-            {
-                dispatch = this.Dequeue(timeout);
-            }
+            MessageDispatch dispatch = this.Dequeue(timeout);
 
             if(dispatch == null)
             {
@@ -192,7 +181,7 @@
             BeforeMessageIsConsumed(dispatch);
             AfterMessageIsConsumed(dispatch, false);
 
-            return CreateActiveMQMessage(dispatch);
+            return CreateStompMessage(dispatch);
         }
 
         public IMessage ReceiveNoWait()
@@ -200,17 +189,7 @@
             CheckClosed();
             CheckMessageListener();
 
-            MessageDispatch dispatch = null;
-            SendPullRequest(-1);
-
-            if(this.PrefetchSize == 0)
-            {
-                dispatch = this.Dequeue(TimeSpan.FromMilliseconds(-1));
-            }
-            else
-            {
-                dispatch = this.Dequeue(TimeSpan.Zero);
-            }
+            MessageDispatch dispatch = this.Dequeue(TimeSpan.Zero);
 
             if(dispatch == null)
             {
@@ -220,7 +199,7 @@
             BeforeMessageIsConsumed(dispatch);
             AfterMessageIsConsumed(dispatch, false);
 
-            return CreateActiveMQMessage(dispatch);
+            return CreateStompMessage(dispatch);
         }
 
         public void Dispose()
@@ -309,25 +288,6 @@
 
         #endregion
 
-        protected void SendPullRequest(long timeout)
-        {
-            if(this.info.PrefetchSize == 0 && this.unconsumedMessages.Empty)
-            {
-                MessagePull messagePull = new MessagePull();
-                messagePull.ConsumerId = this.info.ConsumerId;
-                messagePull.Destination = this.info.Destination;
-                messagePull.Timeout = timeout;
-                messagePull.ResponseRequired = false;
-
-                if(Tracer.IsDebugEnabled)
-                {
-                    Tracer.Debug("Sending MessagePull: " + messagePull);
-                }
-
-                session.Connection.Oneway(messagePull);
-            }
-        }
-
         protected void DoIndividualAcknowledge(Message message)
         {
             MessageDispatch dispatch = null;
@@ -482,7 +442,7 @@
                     {
                         if(listener != null && this.unconsumedMessages.Running)
                         {
-                            ActiveMQMessage message = CreateActiveMQMessage(dispatch);
+                            Message message = CreateStompMessage(dispatch);
 
                             this.BeforeMessageIsConsumed(dispatch);
 

Modified: activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/main/csharp/MessageProducer.cs
URL: http://svn.apache.org/viewvc/activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/main/csharp/MessageProducer.cs?rev=888089&r1=888088&r2=888089&view=diff
==============================================================================
--- activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/main/csharp/MessageProducer.cs (original)
+++ activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/main/csharp/MessageProducer.cs Mon Dec  7 19:09:55 2009
@@ -119,11 +119,6 @@
                     Tracer.ErrorFormat("Error during producer close: {0}", ex);
                 }
 
-                if(this.usage != null)
-                {
-                    this.usage.Stop();
-                }
-
                 closed = true;
             }
         }
@@ -193,7 +188,7 @@
                     throw new ConnectionClosedException();
                 }
 
-                session.DoSend(stompMessage, this, this.usage, this.RequestTimeout);
+                session.DoSend(stompMessage, this, this.RequestTimeout);
             }
         }
 

Modified: activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/main/csharp/Session.cs
URL: http://svn.apache.org/viewvc/activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/main/csharp/Session.cs?rev=888089&r1=888088&r2=888089&view=diff
==============================================================================
--- activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/main/csharp/Session.cs (original)
+++ activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/main/csharp/Session.cs Mon Dec  7 19:09:55 2009
@@ -462,7 +462,7 @@
             RemoveSubscriptionInfo command = new RemoveSubscriptionInfo();
             command.ConnectionId = Connection.ConnectionId;
             command.ClientId = Connection.ClientId;
-            command.SubcriptionName = name;
+            command.SubscriptionName = name;
             this.connection.SyncRequest(command);
         }
 
@@ -478,25 +478,23 @@
 
         public IQueue GetQueue(string name)
         {
-            return new ActiveMQQueue(name);
+            return new Commands.Queue(name);
         }
 
         public ITopic GetTopic(string name)
         {
-            return new ActiveMQTopic(name);
+            return new Commands.Topic(name);
         }
 
         public ITemporaryQueue CreateTemporaryQueue()
         {
-            ActiveMQTempQueue answer = new ActiveMQTempQueue(Connection.CreateTemporaryDestinationName());
-            CreateTemporaryDestination(answer);
+            TempQueue answer = new TempQueue(Connection.CreateTemporaryDestinationName());
             return answer;
         }
 
         public ITemporaryTopic CreateTemporaryTopic()
         {
-            ActiveMQTempTopic answer = new ActiveMQTempTopic(Connection.CreateTemporaryDestinationName());
-            CreateTemporaryDestination(answer);
+            TempTopic answer = new TempTopic(Connection.CreateTemporaryDestinationName());
             return answer;
         }
 
@@ -505,12 +503,7 @@
         /// </summary>
         public void DeleteDestination(IDestination destination)
         {
-            DestinationInfo command = new DestinationInfo();
-            command.ConnectionId = Connection.ConnectionId;
-            command.OperationType = DestinationInfo.REMOVE_OPERATION_TYPE; // 1 is remove
-            command.Destination = (Destination) destination;
-
-            this.connection.Oneway(command);
+            // Not Possible with Stomp
         }
 
         public IMessage CreateMessage()
@@ -521,24 +514,24 @@
 
         public ITextMessage CreateTextMessage()
         {
-            ActiveMQTextMessage answer = new ActiveMQTextMessage();
+            TextMessage answer = new TextMessage();
             return ConfigureMessage(answer) as ITextMessage;
         }
 
         public ITextMessage CreateTextMessage(string text)
         {
-            ActiveMQTextMessage answer = new ActiveMQTextMessage(text);
+            TextMessage answer = new TextMessage(text);
             return ConfigureMessage(answer) as ITextMessage;
         }
 
         public IMapMessage CreateMapMessage()
         {
-            return ConfigureMessage(new ActiveMQMapMessage()) as IMapMessage;
+            return ConfigureMessage(new MapMessage()) as IMapMessage;
         }
 
         public IBytesMessage CreateBytesMessage()
         {
-            return ConfigureMessage(new ActiveMQBytesMessage()) as IBytesMessage;
+            return ConfigureMessage(new BytesMessage()) as IBytesMessage;
         }
 
         public IBytesMessage CreateBytesMessage(byte[] body)
@@ -550,12 +543,12 @@
 
         public IStreamMessage CreateStreamMessage()
         {
-            return ConfigureMessage(new ActiveMQStreamMessage()) as IStreamMessage;
+            return ConfigureMessage(new StreamMessage()) as IStreamMessage;
         }
 
         public IObjectMessage CreateObjectMessage(object body)
         {
-            throw NotSupportedException("No Object Message in Stomp");
+            throw new NotSupportedException("No Object Message in Stomp");
         }
 
         public void Commit()
@@ -584,16 +577,6 @@
 
         #endregion
 
-        protected void CreateTemporaryDestination(Destination tempDestination)
-        {
-            DestinationInfo command = new DestinationInfo();
-            command.ConnectionId = Connection.ConnectionId;
-            command.OperationType = DestinationInfo.ADD_OPERATION_TYPE; // 0 is add
-            command.Destination = tempDestination;
-
-            this.connection.SyncRequest(command);
-        }
-
         public void DoSend( Message message, MessageProducer producer, TimeSpan sendTimeout )
         {
             Message msg = message;
@@ -605,7 +588,6 @@
             }
 
             msg.RedeliveryCounter = 0;
-            msg.BrokerPath = null;
 
             if(this.connection.CopyMessageOnSend)
             {

Modified: activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/main/csharp/TransactionContext.cs
URL: http://svn.apache.org/viewvc/activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/main/csharp/TransactionContext.cs?rev=888089&r1=888088&r2=888089&view=diff
==============================================================================
--- activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/main/csharp/TransactionContext.cs (original)
+++ activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/main/csharp/TransactionContext.cs Mon Dec  7 19:09:55 2009
@@ -110,7 +110,7 @@
             TransactionInfo info = new TransactionInfo();
             info.ConnectionId = this.session.Connection.ConnectionId;
             info.TransactionId = transactionId;
-            info.Type = (int) TransactionType.CommitOnePhase;
+            info.Type = (int) TransactionType.Commit;
 
             this.transactionId = null;
             this.session.Connection.SyncRequest(info);

Modified: activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/main/csharp/Transport/Tcp/TcpTransportFactory.cs
URL: http://svn.apache.org/viewvc/activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/main/csharp/Transport/Tcp/TcpTransportFactory.cs?rev=888089&r1=888088&r2=888089&view=diff
==============================================================================
--- activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/main/csharp/Transport/Tcp/TcpTransportFactory.cs (original)
+++ activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/src/main/csharp/Transport/Tcp/TcpTransportFactory.cs Mon Dec  7 19:09:55 2009
@@ -20,6 +20,7 @@
 using System.Net;
 using System.Net.Sockets;
 using Apache.NMS.Stomp.Transport;
+using Apache.NMS.Stomp.Protocol;
 using Apache.NMS.Util;
 
 namespace Apache.NMS.Stomp.Transport.Tcp
@@ -133,11 +134,6 @@
                 transport = new LoggingTransport(transport);
             }
 
-            if(wireformat is OpenWireFormat)
-            {
-                transport = new WireFormatNegotiator(transport, (OpenWireFormat) wireformat);
-            }
-
             transport.RequestTimeout = this.requestTimeout;
 
             if(setTransport != null)

Modified: activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/vs2008-stomp.csproj
URL: http://svn.apache.org/viewvc/activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/vs2008-stomp.csproj?rev=888089&r1=888088&r2=888089&view=diff
==============================================================================
--- activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/vs2008-stomp.csproj (original)
+++ activemq/activemq-dotnet/Apache.NMS.Stomp/trunk/vs2008-stomp.csproj Mon Dec  7 19:09:55 2009
@@ -104,8 +104,11 @@
     <Compile Include="src\main\csharp\Threads\DedicatedTaskRunner.cs" />
     <Compile Include="src\main\csharp\Threads\Task.cs" />
     <Compile Include="src\main\csharp\Threads\TaskRunner.cs" />
-    <Compile Include="src\main\csharp\Threads\TaskRunnerFactory.cs" />
     <Compile Include="src\main\csharp\Commands\DataStructureTypes.cs" />
+    <Compile Include="src\main\csharp\BrokerException.cs" />
+    <Compile Include="src\main\csharp\ConnectionClosedException.cs" />
+    <Compile Include="src\main\csharp\Commands\ConnectionError.cs" />
+    <Compile Include="src\main\csharp\Commands\RemoveSubscriptionInfo.cs" />
   </ItemGroup>
   <ItemGroup>
     <None Include="keyfile\NMSKey.snk" />