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/07/06 00:36:42 UTC

svn commit: r419371 [8/10] - in /incubator/activemq/trunk/openwire-cpp/src/main/cpp: activemq/ activemq/command/ activemq/protocol/ activemq/protocol/openwire/ activemq/transport/ activemq/transport/tcp/ cms/ ppr/ ppr/io/ ppr/io/encoding/ ppr/net/ ppr/...

Modified: incubator/activemq/trunk/openwire-cpp/src/main/cpp/cms/IQueue.hpp
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/openwire-cpp/src/main/cpp/cms/IQueue.hpp?rev=419371&r1=419370&r2=419371&view=diff
==============================================================================
--- incubator/activemq/trunk/openwire-cpp/src/main/cpp/cms/IQueue.hpp (original)
+++ incubator/activemq/trunk/openwire-cpp/src/main/cpp/cms/IQueue.hpp Wed Jul  5 15:36:36 2006
@@ -1,43 +1,43 @@
-/*
- * 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.
- */
-#ifndef Cms_IQueue_hpp_
-#define Cms_IQueue_hpp_
-
-#include <string>
-#include "cms/IDestination.hpp"
-#include "ppr/util/ifr/p"
-
-namespace apache
-{
-  namespace cms
-  {
-    using namespace ifr;
-    using namespace std;
-
-/*
- * 
- */
-struct IQueue : IDestination
-{
-    virtual p<string> getQueueName() = 0 ;
-} ;
-
-/* namespace */
-  }
-}
-
-#endif /*Cms_IQueue_hpp_*/
+/*
+ * 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.
+ */
+#ifndef Cms_IQueue_hpp_
+#define Cms_IQueue_hpp_
+
+#include <string>
+#include "cms/IDestination.hpp"
+#include "ppr/util/ifr/p"
+
+namespace apache
+{
+  namespace cms
+  {
+    using namespace ifr;
+    using namespace std;
+
+/*
+ * 
+ */
+struct IQueue : IDestination
+{
+    virtual p<string> getQueueName() = 0 ;
+} ;
+
+/* namespace */
+  }
+}
+
+#endif /*Cms_IQueue_hpp_*/

Propchange: incubator/activemq/trunk/openwire-cpp/src/main/cpp/cms/IQueue.hpp
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/activemq/trunk/openwire-cpp/src/main/cpp/cms/ISession.hpp
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/openwire-cpp/src/main/cpp/cms/ISession.hpp?rev=419371&r1=419370&r2=419371&view=diff
==============================================================================
--- incubator/activemq/trunk/openwire-cpp/src/main/cpp/cms/ISession.hpp (original)
+++ incubator/activemq/trunk/openwire-cpp/src/main/cpp/cms/ISession.hpp Wed Jul  5 15:36:36 2006
@@ -1,68 +1,68 @@
-/*
- * 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.
- */
-#ifndef Cms_ISession_hpp_
-#define Cms_ISession_hpp_
-
-#include "cms/IDestination.hpp"
-#include "cms/IMessageProducer.hpp"
-#include "cms/IMessageConsumer.hpp"
-#include "cms/IQueue.hpp"
-#include "cms/ITopic.hpp"
-#include "cms/ITemporaryQueue.hpp"
-#include "cms/ITemporaryTopic.hpp"
-#include "cms/ITextMessage.hpp"
-#include "cms/IBytesMessage.hpp"
-#include "cms/IMapMessage.hpp"
-#include "cms/CmsException.hpp"
-#include "ppr/util/ifr/p"
-
-namespace apache
-{
-  namespace cms
-  {
-    using namespace ifr;
-
-/*
- * 
- */
-struct ISession : Interface
-{
-    virtual void commit() throw(CmsException) = 0 ;
-    virtual void rollback() throw(CmsException) = 0 ;
-    virtual p<IQueue> getQueue(const char* name) = 0 ;
-    virtual p<ITopic> getTopic(const char* name) = 0 ;
-    virtual p<IMessageProducer> createProducer() = 0 ;
-    virtual p<IMessageProducer> createProducer(p<IDestination> destination) = 0 ;
-    virtual p<IMessageConsumer> createConsumer(p<IDestination> destination) = 0 ;
-    virtual p<IMessageConsumer> createConsumer(p<IDestination> destination, const char* selector) = 0 ;
-    virtual p<IMessageConsumer> createDurableConsumer(p<ITopic> destination, const char* name, const char* selector, bool noLocal) = 0 ;
-    virtual p<ITemporaryQueue> createTemporaryQueue() = 0 ;
-    virtual p<ITemporaryTopic> createTemporaryTopic() = 0 ;
-    virtual p<IMessage> createMessage() = 0 ;
-    virtual p<IBytesMessage> createBytesMessage() = 0 ;
-    virtual p<IBytesMessage> createBytesMessage(char* body, int size) = 0 ;
-    virtual p<IMapMessage> createMapMessage() = 0 ;
-    virtual p<ITextMessage> createTextMessage() = 0 ;
-    virtual p<ITextMessage> createTextMessage(const char* text) = 0 ;
-    virtual void close() = 0 ;
-} ;
-
-/* namespace */
-  }
-}
-
-#endif /*Cms_ISession_hpp_*/
+/*
+ * 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.
+ */
+#ifndef Cms_ISession_hpp_
+#define Cms_ISession_hpp_
+
+#include "cms/IDestination.hpp"
+#include "cms/IMessageProducer.hpp"
+#include "cms/IMessageConsumer.hpp"
+#include "cms/IQueue.hpp"
+#include "cms/ITopic.hpp"
+#include "cms/ITemporaryQueue.hpp"
+#include "cms/ITemporaryTopic.hpp"
+#include "cms/ITextMessage.hpp"
+#include "cms/IBytesMessage.hpp"
+#include "cms/IMapMessage.hpp"
+#include "cms/CmsException.hpp"
+#include "ppr/util/ifr/p"
+
+namespace apache
+{
+  namespace cms
+  {
+    using namespace ifr;
+
+/*
+ * 
+ */
+struct ISession : Interface
+{
+    virtual void commit() throw(CmsException) = 0 ;
+    virtual void rollback() throw(CmsException) = 0 ;
+    virtual p<IQueue> getQueue(const char* name) = 0 ;
+    virtual p<ITopic> getTopic(const char* name) = 0 ;
+    virtual p<IMessageProducer> createProducer() = 0 ;
+    virtual p<IMessageProducer> createProducer(p<IDestination> destination) = 0 ;
+    virtual p<IMessageConsumer> createConsumer(p<IDestination> destination) = 0 ;
+    virtual p<IMessageConsumer> createConsumer(p<IDestination> destination, const char* selector) = 0 ;
+    virtual p<IMessageConsumer> createDurableConsumer(p<ITopic> destination, const char* name, const char* selector, bool noLocal) = 0 ;
+    virtual p<ITemporaryQueue> createTemporaryQueue() = 0 ;
+    virtual p<ITemporaryTopic> createTemporaryTopic() = 0 ;
+    virtual p<IMessage> createMessage() = 0 ;
+    virtual p<IBytesMessage> createBytesMessage() = 0 ;
+    virtual p<IBytesMessage> createBytesMessage(char* body, int size) = 0 ;
+    virtual p<IMapMessage> createMapMessage() = 0 ;
+    virtual p<ITextMessage> createTextMessage() = 0 ;
+    virtual p<ITextMessage> createTextMessage(const char* text) = 0 ;
+    virtual void close() = 0 ;
+} ;
+
+/* namespace */
+  }
+}
+
+#endif /*Cms_ISession_hpp_*/

Propchange: incubator/activemq/trunk/openwire-cpp/src/main/cpp/cms/ISession.hpp
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/activemq/trunk/openwire-cpp/src/main/cpp/cms/IStartable.hpp
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/openwire-cpp/src/main/cpp/cms/IStartable.hpp?rev=419371&r1=419370&r2=419371&view=diff
==============================================================================
--- incubator/activemq/trunk/openwire-cpp/src/main/cpp/cms/IStartable.hpp (original)
+++ incubator/activemq/trunk/openwire-cpp/src/main/cpp/cms/IStartable.hpp Wed Jul  5 15:36:36 2006
@@ -1,39 +1,39 @@
-/*
- * 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.
- */
-#ifndef Cms_IStartable_hpp_
-#define Cms_IStartable_hpp_
-
-#include "ppr/util/ifr/p"
-
-namespace apache
-{
-  namespace cms
-  {
-    using namespace ifr;
-/*
- * 
- */
-struct IStartable : Interface
-{
-	virtual void start() = 0 ;
-} ;
-
-/* namespace */
-  }
-}
-
-#endif /*Cms_IStartable_hpp_*/
+/*
+ * 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.
+ */
+#ifndef Cms_IStartable_hpp_
+#define Cms_IStartable_hpp_
+
+#include "ppr/util/ifr/p"
+
+namespace apache
+{
+  namespace cms
+  {
+    using namespace ifr;
+/*
+ * 
+ */
+struct IStartable : Interface
+{
+	virtual void start() = 0 ;
+} ;
+
+/* namespace */
+  }
+}
+
+#endif /*Cms_IStartable_hpp_*/

Propchange: incubator/activemq/trunk/openwire-cpp/src/main/cpp/cms/IStartable.hpp
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/activemq/trunk/openwire-cpp/src/main/cpp/cms/ITemporaryQueue.hpp
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/openwire-cpp/src/main/cpp/cms/ITemporaryQueue.hpp?rev=419371&r1=419370&r2=419371&view=diff
==============================================================================
--- incubator/activemq/trunk/openwire-cpp/src/main/cpp/cms/ITemporaryQueue.hpp (original)
+++ incubator/activemq/trunk/openwire-cpp/src/main/cpp/cms/ITemporaryQueue.hpp Wed Jul  5 15:36:36 2006
@@ -1,38 +1,38 @@
-/*
- * 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.
- */
-#ifndef Cms_ITemporaryQueue_hpp_
-#define Cms_ITemporaryQueue_hpp_
-
-#include "cms/IDestination.hpp"
-
-namespace apache
-{
-  namespace cms
-  {
-
-/*
- * 
- */
-struct ITemporaryQueue : IDestination
-{
-} ;
-
-/* namespace */
-  }
-}
-
-#endif /*Cms_ITemporaryQueue_hpp_*/
+/*
+ * 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.
+ */
+#ifndef Cms_ITemporaryQueue_hpp_
+#define Cms_ITemporaryQueue_hpp_
+
+#include "cms/IDestination.hpp"
+
+namespace apache
+{
+  namespace cms
+  {
+
+/*
+ * 
+ */
+struct ITemporaryQueue : IDestination
+{
+} ;
+
+/* namespace */
+  }
+}
+
+#endif /*Cms_ITemporaryQueue_hpp_*/

Propchange: incubator/activemq/trunk/openwire-cpp/src/main/cpp/cms/ITemporaryQueue.hpp
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/activemq/trunk/openwire-cpp/src/main/cpp/cms/ITemporaryTopic.hpp
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/openwire-cpp/src/main/cpp/cms/ITemporaryTopic.hpp?rev=419371&r1=419370&r2=419371&view=diff
==============================================================================
--- incubator/activemq/trunk/openwire-cpp/src/main/cpp/cms/ITemporaryTopic.hpp (original)
+++ incubator/activemq/trunk/openwire-cpp/src/main/cpp/cms/ITemporaryTopic.hpp Wed Jul  5 15:36:36 2006
@@ -1,38 +1,38 @@
-/*
- * 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.
- */
-#ifndef Cms_ITemporaryTopic_hpp_
-#define Cms_ITemporaryTopic_hpp_
-
-#include "cms/IDestination.hpp"
-
-namespace apache
-{
-  namespace cms
-  {
-
-/*
- * 
- */
-struct ITemporaryTopic : IDestination
-{
-} ;
-
-/* namespace */
-  }
-}
-
-#endif /*Cms_ITemporaryTopic_hpp_*/
+/*
+ * 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.
+ */
+#ifndef Cms_ITemporaryTopic_hpp_
+#define Cms_ITemporaryTopic_hpp_
+
+#include "cms/IDestination.hpp"
+
+namespace apache
+{
+  namespace cms
+  {
+
+/*
+ * 
+ */
+struct ITemporaryTopic : IDestination
+{
+} ;
+
+/* namespace */
+  }
+}
+
+#endif /*Cms_ITemporaryTopic_hpp_*/

Propchange: incubator/activemq/trunk/openwire-cpp/src/main/cpp/cms/ITemporaryTopic.hpp
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/activemq/trunk/openwire-cpp/src/main/cpp/cms/ITextMessage.hpp
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/openwire-cpp/src/main/cpp/cms/ITextMessage.hpp?rev=419371&r1=419370&r2=419371&view=diff
==============================================================================
--- incubator/activemq/trunk/openwire-cpp/src/main/cpp/cms/ITextMessage.hpp (original)
+++ incubator/activemq/trunk/openwire-cpp/src/main/cpp/cms/ITextMessage.hpp Wed Jul  5 15:36:36 2006
@@ -1,42 +1,42 @@
-/*
- * 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.
- */
-#ifndef Cms_ITextMessage_hpp_
-#define Cms_ITextMessage_hpp_
-
-#include <string>
-#include "cms/IMessage.hpp"
-
-namespace apache
-{
-  namespace cms
-  {
-    using namespace std;
-
-/*
- * Represents a text based message.
- */
-struct ITextMessage : IMessage
-{
-    virtual p<string> getText() = 0 ;
-    virtual void setText(const char* txt) = 0 ;
-} ;
-
-/* namespace */
-  }
-}
-
-#endif /*Cms_ITextMessage_hpp_*/
+/*
+ * 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.
+ */
+#ifndef Cms_ITextMessage_hpp_
+#define Cms_ITextMessage_hpp_
+
+#include <string>
+#include "cms/IMessage.hpp"
+
+namespace apache
+{
+  namespace cms
+  {
+    using namespace std;
+
+/*
+ * Represents a text based message.
+ */
+struct ITextMessage : IMessage
+{
+    virtual p<string> getText() = 0 ;
+    virtual void setText(const char* txt) = 0 ;
+} ;
+
+/* namespace */
+  }
+}
+
+#endif /*Cms_ITextMessage_hpp_*/

Propchange: incubator/activemq/trunk/openwire-cpp/src/main/cpp/cms/ITextMessage.hpp
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/activemq/trunk/openwire-cpp/src/main/cpp/cms/ITopic.hpp
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/openwire-cpp/src/main/cpp/cms/ITopic.hpp?rev=419371&r1=419370&r2=419371&view=diff
==============================================================================
--- incubator/activemq/trunk/openwire-cpp/src/main/cpp/cms/ITopic.hpp (original)
+++ incubator/activemq/trunk/openwire-cpp/src/main/cpp/cms/ITopic.hpp Wed Jul  5 15:36:36 2006
@@ -1,43 +1,43 @@
-/*
- * 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.
- */
-#ifndef Cms_ITopic_hpp_
-#define Cms_ITopic_hpp_
-
-#include <string>
-#include "cms/IDestination.hpp"
-#include "ppr/util/ifr/p"
-
-namespace apache
-{
-  namespace cms
-  {
-    using namespace ifr;
-    using namespace std;
-
-/*
- * 
- */
-struct ITopic : IDestination
-{
-    virtual p<string> getTopicName() = 0 ;
-} ;
-
-/* namespace */
-  }
-}
-
-#endif /*Cms_ITopic_hpp_*/
+/*
+ * 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.
+ */
+#ifndef Cms_ITopic_hpp_
+#define Cms_ITopic_hpp_
+
+#include <string>
+#include "cms/IDestination.hpp"
+#include "ppr/util/ifr/p"
+
+namespace apache
+{
+  namespace cms
+  {
+    using namespace ifr;
+    using namespace std;
+
+/*
+ * 
+ */
+struct ITopic : IDestination
+{
+    virtual p<string> getTopicName() = 0 ;
+} ;
+
+/* namespace */
+  }
+}
+
+#endif /*Cms_ITopic_hpp_*/

Propchange: incubator/activemq/trunk/openwire-cpp/src/main/cpp/cms/ITopic.hpp
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/activemq/trunk/openwire-cpp/src/main/cpp/cms/MessageEOFException.hpp
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/openwire-cpp/src/main/cpp/cms/MessageEOFException.hpp?rev=419371&r1=419370&r2=419371&view=diff
==============================================================================
--- incubator/activemq/trunk/openwire-cpp/src/main/cpp/cms/MessageEOFException.hpp (original)
+++ incubator/activemq/trunk/openwire-cpp/src/main/cpp/cms/MessageEOFException.hpp Wed Jul  5 15:36:36 2006
@@ -1,44 +1,44 @@
-/*
- * 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.
- */
-#ifndef Cms_MessageEOFException_hpp_
-#define Cms_MessageEOFException_hpp_
-
-#include "cms/CmsException.hpp"
-
-namespace apache
-{
-  namespace cms
-  {
-
-/*
- * Signals that an unexpected end of stream has been reached when reading
- * a message.
- */
-class MessageEOFException : public CmsException
-{
-public:
-    MessageEOFException() : CmsException()
-       { /* no-op */ } ;
-    MessageEOFException(const char *msg) : CmsException(msg)
-       { /* no-op */ } ;
-} ;
-
-/* namespace */
-  }
-}
-
-#endif /*Cms_MessageEOFException_hpp_*/
+/*
+ * 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.
+ */
+#ifndef Cms_MessageEOFException_hpp_
+#define Cms_MessageEOFException_hpp_
+
+#include "cms/CmsException.hpp"
+
+namespace apache
+{
+  namespace cms
+  {
+
+/*
+ * Signals that an unexpected end of stream has been reached when reading
+ * a message.
+ */
+class MessageEOFException : public CmsException
+{
+public:
+    MessageEOFException() : CmsException()
+       { /* no-op */ } ;
+    MessageEOFException(const char *msg) : CmsException(msg)
+       { /* no-op */ } ;
+} ;
+
+/* namespace */
+  }
+}
+
+#endif /*Cms_MessageEOFException_hpp_*/

Propchange: incubator/activemq/trunk/openwire-cpp/src/main/cpp/cms/MessageEOFException.hpp
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/activemq/trunk/openwire-cpp/src/main/cpp/cms/MessageFormatException.hpp
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/openwire-cpp/src/main/cpp/cms/MessageFormatException.hpp?rev=419371&r1=419370&r2=419371&view=diff
==============================================================================
--- incubator/activemq/trunk/openwire-cpp/src/main/cpp/cms/MessageFormatException.hpp (original)
+++ incubator/activemq/trunk/openwire-cpp/src/main/cpp/cms/MessageFormatException.hpp Wed Jul  5 15:36:36 2006
@@ -1,44 +1,44 @@
-/*
- * 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.
- */
-#ifndef Cms_MessageFormatException_hpp_
-#define Cms_MessageFormatException_hpp_
-
-#include "cms/CmsException.hpp"
-
-namespace apache
-{
-  namespace cms
-  {
-
-/*
- * Signals that a client attempts to use a data type not supported by a
- * message or attempts to read data in a message as the wrong type.
- */
-class MessageFormatException : public CmsException
-{
-public:
-    MessageFormatException() : CmsException()
-       { /* no-op */ } ;
-    MessageFormatException(const char *msg) : CmsException(msg)
-       { /* no-op */ } ;
-} ;
-
-/* namespace */
-  }
-}
-
-#endif /*Cms_MessageFormatException_hpp_*/
+/*
+ * 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.
+ */
+#ifndef Cms_MessageFormatException_hpp_
+#define Cms_MessageFormatException_hpp_
+
+#include "cms/CmsException.hpp"
+
+namespace apache
+{
+  namespace cms
+  {
+
+/*
+ * Signals that a client attempts to use a data type not supported by a
+ * message or attempts to read data in a message as the wrong type.
+ */
+class MessageFormatException : public CmsException
+{
+public:
+    MessageFormatException() : CmsException()
+       { /* no-op */ } ;
+    MessageFormatException(const char *msg) : CmsException(msg)
+       { /* no-op */ } ;
+} ;
+
+/* namespace */
+  }
+}
+
+#endif /*Cms_MessageFormatException_hpp_*/

Propchange: incubator/activemq/trunk/openwire-cpp/src/main/cpp/cms/MessageFormatException.hpp
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/activemq/trunk/openwire-cpp/src/main/cpp/cms/MessageNotReadableException.hpp
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/openwire-cpp/src/main/cpp/cms/MessageNotReadableException.hpp?rev=419371&r1=419370&r2=419371&view=diff
==============================================================================
--- incubator/activemq/trunk/openwire-cpp/src/main/cpp/cms/MessageNotReadableException.hpp (original)
+++ incubator/activemq/trunk/openwire-cpp/src/main/cpp/cms/MessageNotReadableException.hpp Wed Jul  5 15:36:36 2006
@@ -1,43 +1,43 @@
-/*
- * 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.
- */
-#ifndef Cms_MessageNotReadableException_hpp_
-#define Cms_MessageNotReadableException_hpp_
-
-#include "cms/CmsException.hpp"
-
-namespace apache
-{
-  namespace cms
-  {
-
-/*
- * Signals that a message is in read-only mode.
- */
-class MessageNotReadableException : public CmsException
-{
-public:
-    MessageNotReadableException() : CmsException()
-       { /* no-op */ } ;
-    MessageNotReadableException(const char *msg) : CmsException(msg)
-       { /* no-op */ } ;
-} ;
-
-/* namespace */
-  }
-}
-
-#endif /*Cms_MessageNotReadableException_hpp_*/
+/*
+ * 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.
+ */
+#ifndef Cms_MessageNotReadableException_hpp_
+#define Cms_MessageNotReadableException_hpp_
+
+#include "cms/CmsException.hpp"
+
+namespace apache
+{
+  namespace cms
+  {
+
+/*
+ * Signals that a message is in read-only mode.
+ */
+class MessageNotReadableException : public CmsException
+{
+public:
+    MessageNotReadableException() : CmsException()
+       { /* no-op */ } ;
+    MessageNotReadableException(const char *msg) : CmsException(msg)
+       { /* no-op */ } ;
+} ;
+
+/* namespace */
+  }
+}
+
+#endif /*Cms_MessageNotReadableException_hpp_*/

Propchange: incubator/activemq/trunk/openwire-cpp/src/main/cpp/cms/MessageNotReadableException.hpp
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/activemq/trunk/openwire-cpp/src/main/cpp/cms/MessageNotWritableException.hpp
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/openwire-cpp/src/main/cpp/cms/MessageNotWritableException.hpp?rev=419371&r1=419370&r2=419371&view=diff
==============================================================================
--- incubator/activemq/trunk/openwire-cpp/src/main/cpp/cms/MessageNotWritableException.hpp (original)
+++ incubator/activemq/trunk/openwire-cpp/src/main/cpp/cms/MessageNotWritableException.hpp Wed Jul  5 15:36:36 2006
@@ -1,43 +1,43 @@
-/*
- * 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.
- */
-#ifndef Cms_MessageNotWritableException_hpp_
-#define Cms_MessageNotWritableException_hpp_
-
-#include "cms/CmsException.hpp"
-
-namespace apache
-{
-  namespace cms
-  {
-
-/*
- * Signals that a message is in read-only mode.
- */
-class MessageNotWritableException : public CmsException
-{
-public:
-    MessageNotWritableException() : CmsException()
-       { /* no-op */ } ;
-    MessageNotWritableException(const char *msg) : CmsException(msg)
-       { /* no-op */ } ;
-} ;
-
-/* namespace */
-  }
-}
-
-#endif /*Cms_MessageNotWritableException_hpp_*/
+/*
+ * 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.
+ */
+#ifndef Cms_MessageNotWritableException_hpp_
+#define Cms_MessageNotWritableException_hpp_
+
+#include "cms/CmsException.hpp"
+
+namespace apache
+{
+  namespace cms
+  {
+
+/*
+ * Signals that a message is in read-only mode.
+ */
+class MessageNotWritableException : public CmsException
+{
+public:
+    MessageNotWritableException() : CmsException()
+       { /* no-op */ } ;
+    MessageNotWritableException(const char *msg) : CmsException(msg)
+       { /* no-op */ } ;
+} ;
+
+/* namespace */
+  }
+}
+
+#endif /*Cms_MessageNotWritableException_hpp_*/

Propchange: incubator/activemq/trunk/openwire-cpp/src/main/cpp/cms/MessageNotWritableException.hpp
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/ConversionException.hpp
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/ConversionException.hpp?rev=419371&r1=419370&r2=419371&view=diff
==============================================================================
--- incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/ConversionException.hpp (original)
+++ incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/ConversionException.hpp Wed Jul  5 15:36:36 2006
@@ -1,45 +1,45 @@
-/*
- * 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.
- */
-#ifndef Ppr_ConversionException_hpp_
-#define Ppr_ConversionException_hpp_
-
-#include "ppr/TraceException.hpp"
-
-namespace apache
-{
-  namespace ppr
-  {
-
-/*
- * Signals that an illegal data conversion has occurred.
- */
-class ConversionException : public TraceException
-{
-public:
-    ConversionException() : TraceException()
-       { /* no-op */ } ;
-    ConversionException(const char *const& msg) : TraceException(msg)
-       { /* no-op */ } ;
-    ConversionException(const char* fileName, int lineNo, const char* msg) : TraceException(msg)
-       { /* no-op */ } ;
-} ;
-
-/* namespace */
-  }
-}
-
-#endif /*Ppr_ConversionException_hpp_*/
+/*
+ * 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.
+ */
+#ifndef Ppr_ConversionException_hpp_
+#define Ppr_ConversionException_hpp_
+
+#include "ppr/TraceException.hpp"
+
+namespace apache
+{
+  namespace ppr
+  {
+
+/*
+ * Signals that an illegal data conversion has occurred.
+ */
+class ConversionException : public TraceException
+{
+public:
+    ConversionException() : TraceException()
+       { /* no-op */ } ;
+    ConversionException(const char *const& msg) : TraceException(msg)
+       { /* no-op */ } ;
+    ConversionException(const char* fileName, int lineNo, const char* msg) : TraceException(msg)
+       { /* no-op */ } ;
+} ;
+
+/* namespace */
+  }
+}
+
+#endif /*Ppr_ConversionException_hpp_*/

Propchange: incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/ConversionException.hpp
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/IllegalArgumentException.hpp
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/IllegalArgumentException.hpp?rev=419371&r1=419370&r2=419371&view=diff
==============================================================================
--- incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/IllegalArgumentException.hpp (original)
+++ incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/IllegalArgumentException.hpp Wed Jul  5 15:36:36 2006
@@ -1,45 +1,45 @@
-/*
- * 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.
- */
-#ifndef Ppr_IllegalArgumentException_hpp_
-#define Ppr_IllegalArgumentException_hpp_
-
-#include "ppr/TraceException.hpp"
-
-namespace apache
-{
-  namespace ppr
-  {
-
-/*
- * Signals that a method has been passed an illegal or inappropriate argument.
- */
-class IllegalArgumentException : public TraceException
-{
-public:
-    IllegalArgumentException() : TraceException()
-       { /* no-op */ } ;
-    IllegalArgumentException(const char *const& msg) : TraceException(msg)
-       { /* no-op */ } ;
-    IllegalArgumentException(const char* fileName, int lineNo, const char* msg) : TraceException(msg)
-       { /* no-op */ } ;
-} ;
-
-/* namespace */
-  }
-}
-
-#endif /*Ppr_IllegalArgumentException_hpp_*/
+/*
+ * 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.
+ */
+#ifndef Ppr_IllegalArgumentException_hpp_
+#define Ppr_IllegalArgumentException_hpp_
+
+#include "ppr/TraceException.hpp"
+
+namespace apache
+{
+  namespace ppr
+  {
+
+/*
+ * Signals that a method has been passed an illegal or inappropriate argument.
+ */
+class IllegalArgumentException : public TraceException
+{
+public:
+    IllegalArgumentException() : TraceException()
+       { /* no-op */ } ;
+    IllegalArgumentException(const char *const& msg) : TraceException(msg)
+       { /* no-op */ } ;
+    IllegalArgumentException(const char* fileName, int lineNo, const char* msg) : TraceException(msg)
+       { /* no-op */ } ;
+} ;
+
+/* namespace */
+  }
+}
+
+#endif /*Ppr_IllegalArgumentException_hpp_*/

Propchange: incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/IllegalArgumentException.hpp
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/InvalidOperationException.hpp
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/InvalidOperationException.hpp?rev=419371&r1=419370&r2=419371&view=diff
==============================================================================
--- incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/InvalidOperationException.hpp (original)
+++ incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/InvalidOperationException.hpp Wed Jul  5 15:36:36 2006
@@ -1,45 +1,45 @@
-/*
- * 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.
- */
-#ifndef Ppr_InvalidOperationException_hpp_
-#define Ppr_InvalidOperationException_hpp_
-
-#include "ppr/TraceException.hpp"
-
-namespace apache
-{
-  namespace ppr
-  {
-
-/*
- * Signals that an invalid operation has been attempted.
- */
-class InvalidOperationException : public TraceException
-{
-public:
-    InvalidOperationException() : TraceException()
-       { /* no-op */ } ;
-    InvalidOperationException(const char *const& msg) : TraceException(msg)
-       { /* no-op */ } ;
-    InvalidOperationException(const char* fileName, int lineNo, const char* msg) : TraceException(msg)
-       { /* no-op */ } ;
-} ;
-
-/* namespace */
-  }
-}
-
-#endif /*Ppr_IllegalArgumentException_hpp_*/
+/*
+ * 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.
+ */
+#ifndef Ppr_InvalidOperationException_hpp_
+#define Ppr_InvalidOperationException_hpp_
+
+#include "ppr/TraceException.hpp"
+
+namespace apache
+{
+  namespace ppr
+  {
+
+/*
+ * Signals that an invalid operation has been attempted.
+ */
+class InvalidOperationException : public TraceException
+{
+public:
+    InvalidOperationException() : TraceException()
+       { /* no-op */ } ;
+    InvalidOperationException(const char *const& msg) : TraceException(msg)
+       { /* no-op */ } ;
+    InvalidOperationException(const char* fileName, int lineNo, const char* msg) : TraceException(msg)
+       { /* no-op */ } ;
+} ;
+
+/* namespace */
+  }
+}
+
+#endif /*Ppr_IllegalArgumentException_hpp_*/

Propchange: incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/InvalidOperationException.hpp
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/TraceException.hpp
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/TraceException.hpp?rev=419371&r1=419370&r2=419371&view=diff
==============================================================================
--- incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/TraceException.hpp (original)
+++ incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/TraceException.hpp Wed Jul  5 15:36:36 2006
@@ -1,56 +1,56 @@
-/*
- * 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.
- */
-#ifndef Ppr_TraceException_hpp_
-#define Ppr_TraceException_hpp_
-
-#include <exception>
-#include <string>
-#include <stdarg.h>
-#include <stdio.h>
-#include "ppr/util/ifr/array"
-#include "ppr/util/ifr/p"
-
-namespace apache
-{
-  namespace ppr
-  {
-    using namespace std;
-    using namespace ifr;
-
-/*
- * Base class for all exceptions containing trace information.
- */
-class TraceException : public exception
-{
-    string message ;
-
-public:
-    TraceException() ;
-    TraceException(const char* msg, ...) ;
-    virtual ~TraceException() throw () {}
-
-    virtual const char* what() const throw() ;
-
-protected:
-    virtual void buildMessage(const char* format, va_list& vargs) ;
-} ;
-
-/* namespace */
-  }
-}
-
-#endif /*Ppr_TraceException_hpp_*/
+/*
+ * 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.
+ */
+#ifndef Ppr_TraceException_hpp_
+#define Ppr_TraceException_hpp_
+
+#include <exception>
+#include <string>
+#include <stdarg.h>
+#include <stdio.h>
+#include "ppr/util/ifr/array"
+#include "ppr/util/ifr/p"
+
+namespace apache
+{
+  namespace ppr
+  {
+    using namespace std;
+    using namespace ifr;
+
+/*
+ * Base class for all exceptions containing trace information.
+ */
+class TraceException : public exception
+{
+    string message ;
+
+public:
+    TraceException() ;
+    TraceException(const char* msg, ...) ;
+    virtual ~TraceException() throw () {}
+
+    virtual const char* what() const throw() ;
+
+protected:
+    virtual void buildMessage(const char* format, va_list& vargs) ;
+} ;
+
+/* namespace */
+  }
+}
+
+#endif /*Ppr_TraceException_hpp_*/

Propchange: incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/TraceException.hpp
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/io/BufferedInputStream.hpp
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/io/BufferedInputStream.hpp?rev=419371&r1=419370&r2=419371&view=diff
==============================================================================
--- incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/io/BufferedInputStream.hpp (original)
+++ incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/io/BufferedInputStream.hpp Wed Jul  5 15:36:36 2006
@@ -1,74 +1,74 @@
-/* 
- * 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.
- */
-#ifndef Ppr_BufferedInputStream_hpp_
-#define Ppr_BufferedInputStream_hpp_
-
-// Turn off warning message for ignored exception specification
-#ifdef _MSC_VER
-#pragma warning( disable : 4290 )
-#endif
-
-#include <stdlib.h>
-#include "ppr/IllegalArgumentException.hpp"
-#include "ppr/io/IInputStream.hpp"
-#include "ppr/io/IOException.hpp"
-#include "ppr/thread/SimpleMutex.hpp"
-#include "ppr/util/ifr/p"
-
-namespace apache
-{
-  namespace ppr
-  {
-    namespace io
-    {
-      using namespace ifr ;
-      using namespace apache::ppr ;
-      using namespace apache::ppr::thread ;
-
-/*
- * Buffers bytes to provide more efficient reading from an
- * input stream.
- */
-class BufferedInputStream : public IInputStream
-{
-private:
-    p<IInputStream> istream ;
-    char*           buffer ;
-    int             size, position, treshold ;
-
-    // Default buffer size
-    static const int DEFAULT_SIZE = 10240 ;
-
-public:
-    BufferedInputStream(p<IInputStream> istream) ;
-    BufferedInputStream(p<IInputStream> istream, int size) ;
-
-    virtual void close() throw(IOException) ;
-    virtual int read(char* buf, int offset, int length) throw(IOException) ;
-
-private:
-    void checkClosed() throw(IOException) ;
-    void loadBuffer() throw(IOException) ;
-    bool isEOB() ;
-} ;
-
-/* namespace */
-    }
-  }
-}
-
-#endif /*Ppr_BufferedInputStream_hpp_*/
+/* 
+ * 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.
+ */
+#ifndef Ppr_BufferedInputStream_hpp_
+#define Ppr_BufferedInputStream_hpp_
+
+// Turn off warning message for ignored exception specification
+#ifdef _MSC_VER
+#pragma warning( disable : 4290 )
+#endif
+
+#include <stdlib.h>
+#include "ppr/IllegalArgumentException.hpp"
+#include "ppr/io/IInputStream.hpp"
+#include "ppr/io/IOException.hpp"
+#include "ppr/thread/SimpleMutex.hpp"
+#include "ppr/util/ifr/p"
+
+namespace apache
+{
+  namespace ppr
+  {
+    namespace io
+    {
+      using namespace ifr ;
+      using namespace apache::ppr ;
+      using namespace apache::ppr::thread ;
+
+/*
+ * Buffers bytes to provide more efficient reading from an
+ * input stream.
+ */
+class BufferedInputStream : public IInputStream
+{
+private:
+    p<IInputStream> istream ;
+    char*           buffer ;
+    int             size, position, treshold ;
+
+    // Default buffer size
+    static const int DEFAULT_SIZE = 10240 ;
+
+public:
+    BufferedInputStream(p<IInputStream> istream) ;
+    BufferedInputStream(p<IInputStream> istream, int size) ;
+
+    virtual void close() throw(IOException) ;
+    virtual int read(char* buf, int offset, int length) throw(IOException) ;
+
+private:
+    void checkClosed() throw(IOException) ;
+    void loadBuffer() throw(IOException) ;
+    bool isEOB() ;
+} ;
+
+/* namespace */
+    }
+  }
+}
+
+#endif /*Ppr_BufferedInputStream_hpp_*/

Propchange: incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/io/BufferedInputStream.hpp
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/io/BufferedOutputStream.hpp
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/io/BufferedOutputStream.hpp?rev=419371&r1=419370&r2=419371&view=diff
==============================================================================
--- incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/io/BufferedOutputStream.hpp (original)
+++ incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/io/BufferedOutputStream.hpp Wed Jul  5 15:36:36 2006
@@ -1,75 +1,75 @@
-/* 
- * 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.
- */
-#ifndef Ppr_BufferedOutputStream_hpp_
-#define Ppr_BufferedOutputStream_hpp_
-
-// Turn off warning message for ignored exception specification
-#ifdef _MSC_VER
-#pragma warning( disable : 4290 )
-#endif
-
-#include <stdlib.h>
-#include "ppr/IllegalArgumentException.hpp"
-#include "ppr/io/IOutputStream.hpp"
-#include "ppr/io/IOException.hpp"
-#include "ppr/thread/SimpleMutex.hpp"
-#include "ppr/util/ifr/p"
-
-namespace apache
-{
-  namespace ppr
-  {
-    namespace io
-    {
-      using namespace ifr ;
-      using namespace apache::ppr ;
-      using namespace apache::ppr::thread ;
-
-/*
- * Buffers bytes to provide more efficient writing to an
- * output stream.
- */
-class BufferedOutputStream : public IOutputStream
-{
-private:
-    p<IOutputStream> ostream ;
-    char*            buffer ;
-    int              size, position, treshold ;
-
-    // Default buffer size
-    static const int DEFAULT_SIZE = 10240 ;
-
-public:
-    BufferedOutputStream(p<IOutputStream> ostream) ;
-    BufferedOutputStream(p<IOutputStream> ostream, int size) ;
-
-    virtual void close() throw(IOException) ;
-    virtual void flush() throw(IOException) ;
-    virtual int write(const char* buf, int offset, int length) throw(IOException) ;
-
-private:
-    void checkClosed() throw(IOException) ;
-    void flush0() throw(IOException) ;
-    bool isEOB() ;
-} ;
-
-/* namespace */
-    }
-  }
-}
-
-#endif /*Ppr_BufferedOutputStream_hpp_*/
+/* 
+ * 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.
+ */
+#ifndef Ppr_BufferedOutputStream_hpp_
+#define Ppr_BufferedOutputStream_hpp_
+
+// Turn off warning message for ignored exception specification
+#ifdef _MSC_VER
+#pragma warning( disable : 4290 )
+#endif
+
+#include <stdlib.h>
+#include "ppr/IllegalArgumentException.hpp"
+#include "ppr/io/IOutputStream.hpp"
+#include "ppr/io/IOException.hpp"
+#include "ppr/thread/SimpleMutex.hpp"
+#include "ppr/util/ifr/p"
+
+namespace apache
+{
+  namespace ppr
+  {
+    namespace io
+    {
+      using namespace ifr ;
+      using namespace apache::ppr ;
+      using namespace apache::ppr::thread ;
+
+/*
+ * Buffers bytes to provide more efficient writing to an
+ * output stream.
+ */
+class BufferedOutputStream : public IOutputStream
+{
+private:
+    p<IOutputStream> ostream ;
+    char*            buffer ;
+    int              size, position, treshold ;
+
+    // Default buffer size
+    static const int DEFAULT_SIZE = 10240 ;
+
+public:
+    BufferedOutputStream(p<IOutputStream> ostream) ;
+    BufferedOutputStream(p<IOutputStream> ostream, int size) ;
+
+    virtual void close() throw(IOException) ;
+    virtual void flush() throw(IOException) ;
+    virtual int write(const char* buf, int offset, int length) throw(IOException) ;
+
+private:
+    void checkClosed() throw(IOException) ;
+    void flush0() throw(IOException) ;
+    bool isEOB() ;
+} ;
+
+/* namespace */
+    }
+  }
+}
+
+#endif /*Ppr_BufferedOutputStream_hpp_*/

Propchange: incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/io/BufferedOutputStream.hpp
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/io/ByteArrayInputStream.hpp
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/io/ByteArrayInputStream.hpp?rev=419371&r1=419370&r2=419371&view=diff
==============================================================================
--- incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/io/ByteArrayInputStream.hpp (original)
+++ incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/io/ByteArrayInputStream.hpp Wed Jul  5 15:36:36 2006
@@ -1,59 +1,59 @@
-/* 
- * 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.
- */
-#ifndef Ppr_ByteArrayInputStream_hpp_
-#define Ppr_ByteArrayInputStream_hpp_
-
-#include "ppr/io/IInputStream.hpp"
-#include "ppr/io/EOFException.hpp"
-#include "ppr/util/ifr/array"
-#include "ppr/util/ifr/p"
-
-namespace apache
-{
-  namespace ppr
-  {
-    namespace io
-    {
-      using namespace ifr;
-
-/*
- * ByteArrayInputStream reads primitive C++ data types from an
- * in-memory byte array.
- */
-class ByteArrayInputStream : public IInputStream
-{
-private:
-    array<char> body ;
-    int         bodySize,
-                offset ;
-
-public:
-    ByteArrayInputStream(array<char> buffer) ;
-    ~ByteArrayInputStream() ;
-
-    virtual array<char> toArray() ;
-
-    virtual void close() throw(IOException) ;
-    virtual int read(char* buffer, int index, int count) throw(IOException) ;
-} ;
-
-/* namespace */
-    }
-  }
-}
-
-#endif /*Ppr_ByteArrayInputStream_hpp_*/
+/* 
+ * 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.
+ */
+#ifndef Ppr_ByteArrayInputStream_hpp_
+#define Ppr_ByteArrayInputStream_hpp_
+
+#include "ppr/io/IInputStream.hpp"
+#include "ppr/io/EOFException.hpp"
+#include "ppr/util/ifr/array"
+#include "ppr/util/ifr/p"
+
+namespace apache
+{
+  namespace ppr
+  {
+    namespace io
+    {
+      using namespace ifr;
+
+/*
+ * ByteArrayInputStream reads primitive C++ data types from an
+ * in-memory byte array.
+ */
+class ByteArrayInputStream : public IInputStream
+{
+private:
+    array<char> body ;
+    int         bodySize,
+                offset ;
+
+public:
+    ByteArrayInputStream(array<char> buffer) ;
+    ~ByteArrayInputStream() ;
+
+    virtual array<char> toArray() ;
+
+    virtual void close() throw(IOException) ;
+    virtual int read(char* buffer, int index, int count) throw(IOException) ;
+} ;
+
+/* namespace */
+    }
+  }
+}
+
+#endif /*Ppr_ByteArrayInputStream_hpp_*/

Propchange: incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/io/ByteArrayInputStream.hpp
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/io/ByteArrayOutputStream.hpp
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/io/ByteArrayOutputStream.hpp?rev=419371&r1=419370&r2=419371&view=diff
==============================================================================
--- incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/io/ByteArrayOutputStream.hpp (original)
+++ incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/io/ByteArrayOutputStream.hpp Wed Jul  5 15:36:36 2006
@@ -1,67 +1,67 @@
-/* 
- * 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.
- */
-#ifndef Ppr_ByteArrayOutputStream_hpp_
-#define Ppr_ByteArrayOutputStream_hpp_
-
-#include "ppr/io/IOutputStream.hpp"
-#include "ppr/util/ifr/array"
-#include "ppr/util/ifr/p"
-
-namespace apache
-{
-  namespace ppr
-  {
-    namespace io
-    {
-      using namespace ifr;
-
-/*
- * ByteArrayOutputStream writes primitive C++ data types to a
- * in memory byte array.
- */
-class ByteArrayOutputStream : public IOutputStream
-{
-private:
-    array<char> body ;
-    int         bodySize,
-                bodyLength,
-                offset ;
-
-    const static int INITIAL_SIZE = 256 ;
-    const static int EXPAND_SIZE  = 128 ;
-
-public:
-    ByteArrayOutputStream() ;
-    ByteArrayOutputStream(array<char> buffer) ;
-    virtual ~ByteArrayOutputStream() ;
-
-    virtual array<char> toArray() ;
-
-    virtual void close() throw(IOException) ;
-    virtual void flush() throw(IOException) ;
-    virtual int write(const char* buffer, int index, int length) throw(IOException) ;
-
-protected:
-    virtual void expandBody() ;
-} ;
-
-/* namespace */
-    }
-  }
-}
-
-#endif /*Ppr_ByteArrayOutputStream_hpp_*/
+/* 
+ * 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.
+ */
+#ifndef Ppr_ByteArrayOutputStream_hpp_
+#define Ppr_ByteArrayOutputStream_hpp_
+
+#include "ppr/io/IOutputStream.hpp"
+#include "ppr/util/ifr/array"
+#include "ppr/util/ifr/p"
+
+namespace apache
+{
+  namespace ppr
+  {
+    namespace io
+    {
+      using namespace ifr;
+
+/*
+ * ByteArrayOutputStream writes primitive C++ data types to a
+ * in memory byte array.
+ */
+class ByteArrayOutputStream : public IOutputStream
+{
+private:
+    array<char> body ;
+    int         bodySize,
+                bodyLength,
+                offset ;
+
+    const static int INITIAL_SIZE = 256 ;
+    const static int EXPAND_SIZE  = 128 ;
+
+public:
+    ByteArrayOutputStream() ;
+    ByteArrayOutputStream(array<char> buffer) ;
+    virtual ~ByteArrayOutputStream() ;
+
+    virtual array<char> toArray() ;
+
+    virtual void close() throw(IOException) ;
+    virtual void flush() throw(IOException) ;
+    virtual int write(const char* buffer, int index, int length) throw(IOException) ;
+
+protected:
+    virtual void expandBody() ;
+} ;
+
+/* namespace */
+    }
+  }
+}
+
+#endif /*Ppr_ByteArrayOutputStream_hpp_*/

Propchange: incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/io/ByteArrayOutputStream.hpp
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/io/DataInputStream.hpp
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/io/DataInputStream.hpp?rev=419371&r1=419370&r2=419371&view=diff
==============================================================================
--- incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/io/DataInputStream.hpp (original)
+++ incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/io/DataInputStream.hpp Wed Jul  5 15:36:36 2006
@@ -1,79 +1,79 @@
-/* 
- * 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.
- */
-#ifndef Ppr_DataInputStream_hpp_
-#define Ppr_DataInputStream_hpp_
-
-#include "ppr/io/IInputStream.hpp"
-#include "ppr/io/encoding/ICharsetEncoder.hpp"
-#include "ppr/io/encoding/CharsetEncoderRegistry.hpp"
-#include "ppr/io/encoding/CharsetEncodingException.hpp"
-#include "ppr/util/Endian.hpp"
-#include "ppr/util/ifr/p"
-
-namespace apache
-{
-  namespace ppr
-  {
-    namespace io
-    {
-      using namespace ifr;
-      using namespace apache::ppr::util; //htonx and ntohx functions.
-      using namespace apache::ppr::io::encoding;
-
-/*
- * The DataInputStream class reads primitive C++ data types from an
- * underlying input stream in a Java compatible way. Strings are
- * read as raw bytes or decoded should encoding have been configured.
- *
- * All numeric data types are assumed to be available in big
- * endian (network byte order) and are converted automatically
- * to little endian if needed by the platform.
- *
- * Should any error occur an IOException will be thrown.
- */
-class DataInputStream : public IInputStream
-{
-private:
-    p<IInputStream>    istream ;
-    p<ICharsetEncoder> encoder ;
-
-public:
-    DataInputStream(p<IInputStream> istream) ;
-    DataInputStream(p<IInputStream> istream, const char* encname) ;
-    virtual ~DataInputStream() ;
-
-    virtual void close() throw(IOException) ;
-    virtual int read(char* buffer, int offset, int length) throw(IOException) ;
-    virtual char readByte() throw(IOException) ;
-    virtual bool readBoolean() throw(IOException) ;
-    virtual double readDouble() throw(IOException) ;
-    virtual float readFloat() throw(IOException) ;
-    virtual short readShort() throw(IOException) ;
-    virtual int readInt() throw(IOException) ;
-    virtual long long readLong() throw(IOException) ;
-    virtual p<string> readString() throw(IOException) ;
-
-protected:
-    void checkClosed() throw(IOException) ;
-} ;
-
-/* namespace */
-    }
-  }
-}
-
-#endif /*Ppr_DataInputStream_hpp_*/
+/* 
+ * 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.
+ */
+#ifndef Ppr_DataInputStream_hpp_
+#define Ppr_DataInputStream_hpp_
+
+#include "ppr/io/IInputStream.hpp"
+#include "ppr/io/encoding/ICharsetEncoder.hpp"
+#include "ppr/io/encoding/CharsetEncoderRegistry.hpp"
+#include "ppr/io/encoding/CharsetEncodingException.hpp"
+#include "ppr/util/Endian.hpp"
+#include "ppr/util/ifr/p"
+
+namespace apache
+{
+  namespace ppr
+  {
+    namespace io
+    {
+      using namespace ifr;
+      using namespace apache::ppr::util; //htonx and ntohx functions.
+      using namespace apache::ppr::io::encoding;
+
+/*
+ * The DataInputStream class reads primitive C++ data types from an
+ * underlying input stream in a Java compatible way. Strings are
+ * read as raw bytes or decoded should encoding have been configured.
+ *
+ * All numeric data types are assumed to be available in big
+ * endian (network byte order) and are converted automatically
+ * to little endian if needed by the platform.
+ *
+ * Should any error occur an IOException will be thrown.
+ */
+class DataInputStream : public IInputStream
+{
+private:
+    p<IInputStream>    istream ;
+    p<ICharsetEncoder> encoder ;
+
+public:
+    DataInputStream(p<IInputStream> istream) ;
+    DataInputStream(p<IInputStream> istream, const char* encname) ;
+    virtual ~DataInputStream() ;
+
+    virtual void close() throw(IOException) ;
+    virtual int read(char* buffer, int offset, int length) throw(IOException) ;
+    virtual char readByte() throw(IOException) ;
+    virtual bool readBoolean() throw(IOException) ;
+    virtual double readDouble() throw(IOException) ;
+    virtual float readFloat() throw(IOException) ;
+    virtual short readShort() throw(IOException) ;
+    virtual int readInt() throw(IOException) ;
+    virtual long long readLong() throw(IOException) ;
+    virtual p<string> readString() throw(IOException) ;
+
+protected:
+    void checkClosed() throw(IOException) ;
+} ;
+
+/* namespace */
+    }
+  }
+}
+
+#endif /*Ppr_DataInputStream_hpp_*/

Propchange: incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/io/DataInputStream.hpp
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/io/DataOutputStream.hpp
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/io/DataOutputStream.hpp?rev=419371&r1=419370&r2=419371&view=diff
==============================================================================
--- incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/io/DataOutputStream.hpp (original)
+++ incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/io/DataOutputStream.hpp Wed Jul  5 15:36:36 2006
@@ -1,81 +1,81 @@
-/* 
- * 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.
- */
-#ifndef Ppr_DataOutputStream_hpp_
-#define Ppr_DataOutputStream_hpp_
-
-#include "ppr/io/IOutputStream.hpp"
-#include "ppr/io/encoding/ICharsetEncoder.hpp"
-#include "ppr/io/encoding/CharsetEncoderRegistry.hpp"
-#include "ppr/io/encoding/CharsetEncodingException.hpp"
-#include "ppr/util/Endian.hpp"
-#include "ppr/util/ifr/p"
-
-namespace apache
-{
-  namespace ppr
-  {
-    namespace io
-    {
-      using namespace ifr;
-      using namespace apache::ppr::util; // htonx and ntohx functions.
-      using namespace apache::ppr::io::encoding;
-
-/*
- * The DataOutputStream class writes primitive C++ data types to an
- * underlying output stream in a Java compatible way. Strings
- * are written as either raw bytes or encoded should encoding
- * have been configured.
- *
- * All numeric data types are written in big endian (network byte
- * order) and if the platform is little endian they are converted
- * automatically.
- *
- * Should any error occur an IOException will be thrown.
- */
-class DataOutputStream : public IOutputStream
-{
-private:
-    p<IOutputStream>   ostream ;
-    p<ICharsetEncoder> encoder ;
-
-public:
-    DataOutputStream(p<IOutputStream> ostream) ;
-    DataOutputStream(p<IOutputStream> ostream, const char* encname) ;
-    virtual ~DataOutputStream() ;
-
-    virtual void close() throw(IOException) ;
-    virtual void flush() throw(IOException) ;
-    virtual int write(const char* buffer, int offset, int length) throw(IOException) ;
-    virtual void writeByte(char v) throw(IOException) ;
-    virtual void writeBoolean(bool v) throw(IOException) ;
-    virtual void writeDouble(double v) throw(IOException) ;
-    virtual void writeFloat(float v) throw(IOException) ;
-    virtual void writeShort(short v) throw(IOException) ;
-    virtual void writeInt(int v) throw(IOException) ;
-    virtual void writeLong(long long v) throw(IOException) ;
-    virtual int writeString(p<string> v) throw(IOException) ;
-
-protected:
-    void checkClosed() throw(IOException) ;
-} ;
-
-/* namespace */
-    }
-  }
-}
-
-#endif /*Ppr_DataOutputStream_hpp_*/
+/* 
+ * 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.
+ */
+#ifndef Ppr_DataOutputStream_hpp_
+#define Ppr_DataOutputStream_hpp_
+
+#include "ppr/io/IOutputStream.hpp"
+#include "ppr/io/encoding/ICharsetEncoder.hpp"
+#include "ppr/io/encoding/CharsetEncoderRegistry.hpp"
+#include "ppr/io/encoding/CharsetEncodingException.hpp"
+#include "ppr/util/Endian.hpp"
+#include "ppr/util/ifr/p"
+
+namespace apache
+{
+  namespace ppr
+  {
+    namespace io
+    {
+      using namespace ifr;
+      using namespace apache::ppr::util; // htonx and ntohx functions.
+      using namespace apache::ppr::io::encoding;
+
+/*
+ * The DataOutputStream class writes primitive C++ data types to an
+ * underlying output stream in a Java compatible way. Strings
+ * are written as either raw bytes or encoded should encoding
+ * have been configured.
+ *
+ * All numeric data types are written in big endian (network byte
+ * order) and if the platform is little endian they are converted
+ * automatically.
+ *
+ * Should any error occur an IOException will be thrown.
+ */
+class DataOutputStream : public IOutputStream
+{
+private:
+    p<IOutputStream>   ostream ;
+    p<ICharsetEncoder> encoder ;
+
+public:
+    DataOutputStream(p<IOutputStream> ostream) ;
+    DataOutputStream(p<IOutputStream> ostream, const char* encname) ;
+    virtual ~DataOutputStream() ;
+
+    virtual void close() throw(IOException) ;
+    virtual void flush() throw(IOException) ;
+    virtual int write(const char* buffer, int offset, int length) throw(IOException) ;
+    virtual void writeByte(char v) throw(IOException) ;
+    virtual void writeBoolean(bool v) throw(IOException) ;
+    virtual void writeDouble(double v) throw(IOException) ;
+    virtual void writeFloat(float v) throw(IOException) ;
+    virtual void writeShort(short v) throw(IOException) ;
+    virtual void writeInt(int v) throw(IOException) ;
+    virtual void writeLong(long long v) throw(IOException) ;
+    virtual int writeString(p<string> v) throw(IOException) ;
+
+protected:
+    void checkClosed() throw(IOException) ;
+} ;
+
+/* namespace */
+    }
+  }
+}
+
+#endif /*Ppr_DataOutputStream_hpp_*/

Propchange: incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/io/DataOutputStream.hpp
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/io/EOFException.hpp
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/io/EOFException.hpp?rev=419371&r1=419370&r2=419371&view=diff
==============================================================================
--- incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/io/EOFException.hpp (original)
+++ incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/io/EOFException.hpp Wed Jul  5 15:36:36 2006
@@ -1,53 +1,53 @@
-/*
- * 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.
- */
-#ifndef Ppr_EOFException_hpp_
-#define Ppr_EOFException_hpp_
-
-#include "ppr/io/IOException.hpp"
-
-namespace apache
-{
-  namespace ppr
-  {
-    namespace io
-    {
-      using namespace apache::ppr;
-      using namespace std ;
-
-/*
- * Signals that end-of-file has been reached.
- */
-class EOFException : public IOException
-{
-public:
-    EOFException() : IOException()
-    { /* no-op */ } ;
-    EOFException(const char* msg, ...)
-    {
-        va_list vargs ;
-
-        va_start(vargs, msg) ;
-        TraceException::buildMessage(msg, vargs) ;
-    }
-} ;
-
-/* namespace */
-    }
-  }
-}
-
-#endif /*Ppr_EOFException_hpp_*/
+/*
+ * 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.
+ */
+#ifndef Ppr_EOFException_hpp_
+#define Ppr_EOFException_hpp_
+
+#include "ppr/io/IOException.hpp"
+
+namespace apache
+{
+  namespace ppr
+  {
+    namespace io
+    {
+      using namespace apache::ppr;
+      using namespace std ;
+
+/*
+ * Signals that end-of-file has been reached.
+ */
+class EOFException : public IOException
+{
+public:
+    EOFException() : IOException()
+    { /* no-op */ } ;
+    EOFException(const char* msg, ...)
+    {
+        va_list vargs ;
+
+        va_start(vargs, msg) ;
+        TraceException::buildMessage(msg, vargs) ;
+    }
+} ;
+
+/* namespace */
+    }
+  }
+}
+
+#endif /*Ppr_EOFException_hpp_*/

Propchange: incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/io/EOFException.hpp
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/io/IInputStream.hpp
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/io/IInputStream.hpp?rev=419371&r1=419370&r2=419371&view=diff
==============================================================================
--- incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/io/IInputStream.hpp (original)
+++ incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/io/IInputStream.hpp Wed Jul  5 15:36:36 2006
@@ -1,55 +1,55 @@
-/*
- * 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.
- */
-#ifndef Ppr_IInputStream_hpp_
-#define Ppr_IInputStream_hpp_
-
-// Turn off warning message for ignored exception specification
-#ifdef _MSC_VER
-#pragma warning( disable : 4290 )
-#endif
-
-#include <string>
-#include "ppr/io/IOException.hpp"
-#include "ppr/util/ifr/p"
-
-namespace apache
-{
-  namespace ppr
-  {
-    namespace io
-    {
-      using namespace std;
-      using namespace ifr;
-
-/*
- * The IInputStream interface provides for reading bytes from a binary stream
- * and reconstructing from them data in any of the C++ primitive types.
- * Strings are read as raw bytes, no character decoding is performed. If
- * any byte cannot be read for any reason, an IOException is thrown.
- */
-struct IInputStream : Interface
-{
-    virtual void close() throw(IOException) = 0 ;
-    virtual int read(char* buffer, int index, int count) throw(IOException) = 0 ;
-} ;
-
-/* namespace */
-    }
-  }
-}
-
-#endif /*Ppr_IInputStream_hpp_*/
+/*
+ * 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.
+ */
+#ifndef Ppr_IInputStream_hpp_
+#define Ppr_IInputStream_hpp_
+
+// Turn off warning message for ignored exception specification
+#ifdef _MSC_VER
+#pragma warning( disable : 4290 )
+#endif
+
+#include <string>
+#include "ppr/io/IOException.hpp"
+#include "ppr/util/ifr/p"
+
+namespace apache
+{
+  namespace ppr
+  {
+    namespace io
+    {
+      using namespace std;
+      using namespace ifr;
+
+/*
+ * The IInputStream interface provides for reading bytes from a binary stream
+ * and reconstructing from them data in any of the C++ primitive types.
+ * Strings are read as raw bytes, no character decoding is performed. If
+ * any byte cannot be read for any reason, an IOException is thrown.
+ */
+struct IInputStream : Interface
+{
+    virtual void close() throw(IOException) = 0 ;
+    virtual int read(char* buffer, int index, int count) throw(IOException) = 0 ;
+} ;
+
+/* namespace */
+    }
+  }
+}
+
+#endif /*Ppr_IInputStream_hpp_*/

Propchange: incubator/activemq/trunk/openwire-cpp/src/main/cpp/ppr/io/IInputStream.hpp
------------------------------------------------------------------------------
    svn:eol-style = native