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

svn commit: r427057 [19/22] - in /incubator/activemq/trunk/amazon: ./ amq_brokersession/ amq_corelib/ amq_examples/ amq_examples/bs_async_recv/ amq_examples/bs_send/ amq_examples/bs_sync_recv/ amq_examples/cl_send/ amq_transport/ command/ marshal/

Added: incubator/activemq/trunk/amazon/marshal/IReader.h
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/amazon/marshal/IReader.h?rev=427057&view=auto
==============================================================================
--- incubator/activemq/trunk/amazon/marshal/IReader.h (added)
+++ incubator/activemq/trunk/amazon/marshal/IReader.h Mon Jul 31 02:36:40 2006
@@ -0,0 +1,54 @@
+/*
+  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.
+*/
+#ifndef IReader_hpp_
+#define IReader_hpp_
+
+#include <inttypes.h>
+
+#include <string>
+#include <vector>
+
+namespace ActiveMQ {
+  namespace IO {
+
+    /*
+     * The IReader 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.
+     */
+    class IReader
+    {
+      public:
+        virtual ~IReader() {};
+
+        virtual void close() = 0;
+        virtual int read(uint8_t* buffer, size_t size) = 0;
+        virtual unsigned char readByte() = 0;
+        virtual bool readBoolean() = 0;
+        virtual double readDouble() = 0;
+        virtual float readFloat() = 0;
+        virtual short readShort() = 0;
+        virtual int readInt() = 0;
+        virtual int64_t readLong() = 0;
+        virtual std::string readString() = 0;
+    };
+  }
+}
+
+#endif /*IReader_hpp_*/

Propchange: incubator/activemq/trunk/amazon/marshal/IReader.h
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/activemq/trunk/amazon/marshal/IReader.h
------------------------------------------------------------------------------
    svn:keywords = Date Author Id Revision HeadURL

Added: incubator/activemq/trunk/amazon/marshal/IWriter.h
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/amazon/marshal/IWriter.h?rev=427057&view=auto
==============================================================================
--- incubator/activemq/trunk/amazon/marshal/IWriter.h (added)
+++ incubator/activemq/trunk/amazon/marshal/IWriter.h Mon Jul 31 02:36:40 2006
@@ -0,0 +1,56 @@
+/*
+  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.
+*/
+#ifndef IWriter_hpp_
+#define IWriter_hpp_
+
+#include <sys/types.h>
+#include <inttypes.h>
+#include <string>
+
+namespace ActiveMQ {
+  namespace IO {
+
+    /*
+     * The IWriter interface provides for converting data from any of the
+     * C++ primitive types to a series of bytes and writing these bytes to
+     * a binary stream. Strings are written as raw bytes, no character
+     * encoding is performed. If a byte cannot be written for any reason,
+     * an IOException is thrown. 
+     */
+    class IWriter
+    {
+      public:
+        virtual ~IWriter() {};  // Needed for SP's
+
+        virtual void close() = 0;
+        virtual void flush() = 0;
+        virtual int write(const uint8_t* buffer, size_t size) = 0;
+        virtual void writeByte(uint8_t v) = 0;
+        virtual void writeBoolean(bool v) = 0;
+        virtual void writeDouble(double v) = 0;
+        virtual void writeFloat(float v) = 0;
+        virtual void writeShort(short v) = 0;
+        virtual void writeInt(int v) = 0;
+        virtual void writeLong(int64_t v) = 0;
+        virtual void writeString(const std::string& v) = 0;
+    };
+  }
+}
+
+#endif /*IWriter_hpp_*/

Propchange: incubator/activemq/trunk/amazon/marshal/IWriter.h
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/activemq/trunk/amazon/marshal/IWriter.h
------------------------------------------------------------------------------
    svn:keywords = Date Author Id Revision HeadURL

Added: incubator/activemq/trunk/amazon/marshal/IntegerResponseMarshaller.cpp
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/amazon/marshal/IntegerResponseMarshaller.cpp?rev=427057&view=auto
==============================================================================
--- incubator/activemq/trunk/amazon/marshal/IntegerResponseMarshaller.cpp (added)
+++ incubator/activemq/trunk/amazon/marshal/IntegerResponseMarshaller.cpp Mon Jul 31 02:36:40 2006
@@ -0,0 +1,95 @@
+/*
+  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.
+*/
+
+#include "netinet/in.h"
+#include "marshal/IntegerResponseMarshaller.h"
+#include "command/IntegerResponse.h"
+#include "boost/shared_ptr.hpp"
+
+using namespace ActiveMQ::Marshalling;
+using namespace ActiveMQ::Command;
+using namespace ActiveMQ::IO;
+using std::auto_ptr;
+using boost::shared_ptr;
+
+/*
+ *  Marshalling code for Open Wire Format for IntegerResponse
+ *
+ * NOTE!: This file is autogenerated - do not modify!
+ *        if you need to make a change, please see the Groovy scripts in the
+ *        activemq-core module
+ */
+
+IntegerResponseMarshaller::IntegerResponseMarshaller()
+{
+    // no-op
+}
+
+IntegerResponseMarshaller::~IntegerResponseMarshaller()
+{
+    // no-op
+}
+
+auto_ptr<IDataStructure> IntegerResponseMarshaller::createCommand() 
+{
+    return auto_ptr<IDataStructure>(new IntegerResponse());
+}
+
+char IntegerResponseMarshaller::getDataStructureType() 
+{
+    return IntegerResponse::TYPE;
+}
+
+/* 
+ * Un-marshal an object instance from the data input stream
+ */ 
+void
+IntegerResponseMarshaller::unmarshal(ProtocolFormat& wireFormat, IDataStructure& o, BinaryReader& dataIn, BooleanStream& bs) 
+{
+    ResponseMarshaller::unmarshal(wireFormat, o, dataIn, bs);
+
+    IntegerResponse& info = (IntegerResponse&) o;
+    info.setResult( dataIn.readInt() );
+
+}
+
+/*
+ * Write the booleans that this object uses to a BooleanStream
+ */
+size_t
+IntegerResponseMarshaller::marshal1(ProtocolFormat& wireFormat, const IDataStructure& o, BooleanStream& bs) {
+    IntegerResponse& info = (IntegerResponse&) o;
+
+    int rc = ResponseMarshaller::marshal1(wireFormat, info, bs);
+    
+    return rc + 4;
+}
+
+/* 
+ * Write a object instance to data output stream
+ */
+void
+IntegerResponseMarshaller::marshal2(ProtocolFormat& wireFormat, const IDataStructure& o, BinaryWriter& dataOut, BooleanStream& bs) {
+    // }
+
+    ResponseMarshaller::marshal2(wireFormat, o, dataOut, bs);
+
+    IntegerResponse& info = (IntegerResponse&) o;
+    dataOut.writeInt(info.getResult());
+}

Propchange: incubator/activemq/trunk/amazon/marshal/IntegerResponseMarshaller.cpp
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/activemq/trunk/amazon/marshal/IntegerResponseMarshaller.cpp
------------------------------------------------------------------------------
    svn:keywords = Date Author Id Revision HeadURL

Added: incubator/activemq/trunk/amazon/marshal/IntegerResponseMarshaller.h
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/amazon/marshal/IntegerResponseMarshaller.h?rev=427057&view=auto
==============================================================================
--- incubator/activemq/trunk/amazon/marshal/IntegerResponseMarshaller.h (added)
+++ incubator/activemq/trunk/amazon/marshal/IntegerResponseMarshaller.h Mon Jul 31 02:36:40 2006
@@ -0,0 +1,72 @@
+/*
+  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.
+*/
+
+#ifndef IntegerResponseMarshaller_h_
+#define IntegerResponseMarshaller_h_
+
+#include <string>
+#include <memory>
+
+#include "command/IDataStructure.h"
+
+/* auto-generated! */
+/* we could cut this down  - for now include all possible headers */
+#include "command/BrokerId.h"
+#include "command/ConnectionId.h"
+#include "command/ConsumerId.h"
+#include "command/ProducerId.h"
+#include "command/SessionId.h"
+#include "command/BaseCommand.h"
+
+#include "marshal/BinaryReader.h"
+#include "marshal/BinaryWriter.h"
+
+#include "marshal/ResponseMarshaller.h"
+
+#include "marshal/ProtocolFormat.h"
+
+namespace ActiveMQ {
+  namespace Marshalling {
+
+    class IntegerResponseMarshaller : public ResponseMarshaller
+    {
+    public:
+        IntegerResponseMarshaller();
+        virtual ~IntegerResponseMarshaller();
+
+        virtual auto_ptr<ActiveMQ::Command::IDataStructure> createCommand();
+        virtual char getDataStructureType();
+        
+        virtual void unmarshal(ProtocolFormat& wireFormat,
+                     ActiveMQ::Command::IDataStructure& o,
+                     ActiveMQ::IO::BinaryReader& dataIn,
+                     ActiveMQ::IO::BooleanStream& bs);
+
+        virtual size_t marshal1(ProtocolFormat& wireFormat, 
+                             const ActiveMQ::Command::IDataStructure& o,
+                             ActiveMQ::IO::BooleanStream& bs);
+
+        virtual void marshal2(ProtocolFormat& wireFormat, 
+                              const ActiveMQ::Command::IDataStructure& o,
+                              ActiveMQ::IO::BinaryWriter& dataOut,
+                              ActiveMQ::IO::BooleanStream& bs);
+    };
+  }
+}
+#endif /*IntegerResponseMarshaller_h_*/

Propchange: incubator/activemq/trunk/amazon/marshal/IntegerResponseMarshaller.h
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/activemq/trunk/amazon/marshal/IntegerResponseMarshaller.h
------------------------------------------------------------------------------
    svn:keywords = Date Author Id Revision HeadURL

Added: incubator/activemq/trunk/amazon/marshal/JournalQueueAckMarshaller.cpp
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/amazon/marshal/JournalQueueAckMarshaller.cpp?rev=427057&view=auto
==============================================================================
--- incubator/activemq/trunk/amazon/marshal/JournalQueueAckMarshaller.cpp (added)
+++ incubator/activemq/trunk/amazon/marshal/JournalQueueAckMarshaller.cpp Mon Jul 31 02:36:40 2006
@@ -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.
+*/
+
+#include "netinet/in.h"
+#include "marshal/JournalQueueAckMarshaller.h"
+#include "command/JournalQueueAck.h"
+#include "boost/shared_ptr.hpp"
+
+using namespace ActiveMQ::Marshalling;
+using namespace ActiveMQ::Command;
+using namespace ActiveMQ::IO;
+using std::auto_ptr;
+using boost::shared_ptr;
+
+/*
+ *  Marshalling code for Open Wire Format for JournalQueueAck
+ *
+ * NOTE!: This file is autogenerated - do not modify!
+ *        if you need to make a change, please see the Groovy scripts in the
+ *        activemq-core module
+ */
+
+JournalQueueAckMarshaller::JournalQueueAckMarshaller()
+{
+    // no-op
+}
+
+JournalQueueAckMarshaller::~JournalQueueAckMarshaller()
+{
+    // no-op
+}
+
+auto_ptr<IDataStructure> JournalQueueAckMarshaller::createCommand() 
+{
+    return auto_ptr<IDataStructure>(new JournalQueueAck());
+}
+
+char JournalQueueAckMarshaller::getDataStructureType() 
+{
+    return JournalQueueAck::TYPE;
+}
+
+/* 
+ * Un-marshal an object instance from the data input stream
+ */ 
+void
+JournalQueueAckMarshaller::unmarshal(ProtocolFormat& wireFormat, IDataStructure& o, BinaryReader& dataIn, BooleanStream& bs) 
+{
+
+    JournalQueueAck& info = (JournalQueueAck&) o;
+    info.setDestination( shared_ptr<ActiveMQDestination>(static_cast<ActiveMQDestination*>(unmarshalNestedObject(wireFormat, dataIn, bs).release())) );
+    info.setMessageAck( shared_ptr<MessageAck>(static_cast<MessageAck*>(unmarshalNestedObject(wireFormat, dataIn, bs).release())) );
+
+}
+
+/*
+ * Write the booleans that this object uses to a BooleanStream
+ */
+size_t
+JournalQueueAckMarshaller::marshal1(ProtocolFormat& wireFormat, const IDataStructure& o, BooleanStream& bs) {
+    JournalQueueAck& info = (JournalQueueAck&) o;
+
+    int rc = 0;
+    rc += marshal1NestedObject(wireFormat, info.getDestination(), bs);
+    rc += marshal1NestedObject(wireFormat, info.getMessageAck(), bs);
+
+    return rc + 0;
+}
+
+/* 
+ * Write a object instance to data output stream
+ */
+void
+JournalQueueAckMarshaller::marshal2(ProtocolFormat& wireFormat, const IDataStructure& o, BinaryWriter& dataOut, BooleanStream& bs) {
+    // }
+
+
+    JournalQueueAck& info = (JournalQueueAck&) o;
+    marshal2NestedObject(wireFormat, info.getDestination(), dataOut, bs);
+    marshal2NestedObject(wireFormat, info.getMessageAck(), dataOut, bs);
+}

Propchange: incubator/activemq/trunk/amazon/marshal/JournalQueueAckMarshaller.cpp
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/activemq/trunk/amazon/marshal/JournalQueueAckMarshaller.cpp
------------------------------------------------------------------------------
    svn:keywords = Date Author Id Revision HeadURL

Added: incubator/activemq/trunk/amazon/marshal/JournalQueueAckMarshaller.h
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/amazon/marshal/JournalQueueAckMarshaller.h?rev=427057&view=auto
==============================================================================
--- incubator/activemq/trunk/amazon/marshal/JournalQueueAckMarshaller.h (added)
+++ incubator/activemq/trunk/amazon/marshal/JournalQueueAckMarshaller.h Mon Jul 31 02:36:40 2006
@@ -0,0 +1,72 @@
+/*
+  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.
+*/
+
+#ifndef JournalQueueAckMarshaller_h_
+#define JournalQueueAckMarshaller_h_
+
+#include <string>
+#include <memory>
+
+#include "command/IDataStructure.h"
+
+/* auto-generated! */
+/* we could cut this down  - for now include all possible headers */
+#include "command/BrokerId.h"
+#include "command/ConnectionId.h"
+#include "command/ConsumerId.h"
+#include "command/ProducerId.h"
+#include "command/SessionId.h"
+#include "command/BaseCommand.h"
+
+#include "marshal/BinaryReader.h"
+#include "marshal/BinaryWriter.h"
+
+#include "marshal/BaseDataStreamMarshaller.h"
+
+#include "marshal/ProtocolFormat.h"
+
+namespace ActiveMQ {
+  namespace Marshalling {
+
+    class JournalQueueAckMarshaller : public BaseDataStreamMarshaller
+    {
+    public:
+        JournalQueueAckMarshaller();
+        virtual ~JournalQueueAckMarshaller();
+
+        virtual auto_ptr<ActiveMQ::Command::IDataStructure> createCommand();
+        virtual char getDataStructureType();
+        
+        virtual void unmarshal(ProtocolFormat& wireFormat,
+                     ActiveMQ::Command::IDataStructure& o,
+                     ActiveMQ::IO::BinaryReader& dataIn,
+                     ActiveMQ::IO::BooleanStream& bs);
+
+        virtual size_t marshal1(ProtocolFormat& wireFormat, 
+                             const ActiveMQ::Command::IDataStructure& o,
+                             ActiveMQ::IO::BooleanStream& bs);
+
+        virtual void marshal2(ProtocolFormat& wireFormat, 
+                              const ActiveMQ::Command::IDataStructure& o,
+                              ActiveMQ::IO::BinaryWriter& dataOut,
+                              ActiveMQ::IO::BooleanStream& bs);
+    };
+  }
+}
+#endif /*JournalQueueAckMarshaller_h_*/

Propchange: incubator/activemq/trunk/amazon/marshal/JournalQueueAckMarshaller.h
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/activemq/trunk/amazon/marshal/JournalQueueAckMarshaller.h
------------------------------------------------------------------------------
    svn:keywords = Date Author Id Revision HeadURL

Added: incubator/activemq/trunk/amazon/marshal/JournalTopicAckMarshaller.cpp
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/amazon/marshal/JournalTopicAckMarshaller.cpp?rev=427057&view=auto
==============================================================================
--- incubator/activemq/trunk/amazon/marshal/JournalTopicAckMarshaller.cpp (added)
+++ incubator/activemq/trunk/amazon/marshal/JournalTopicAckMarshaller.cpp Mon Jul 31 02:36:40 2006
@@ -0,0 +1,109 @@
+/*
+  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.
+*/
+
+#include "netinet/in.h"
+#include "marshal/JournalTopicAckMarshaller.h"
+#include "command/JournalTopicAck.h"
+#include "boost/shared_ptr.hpp"
+
+using namespace ActiveMQ::Marshalling;
+using namespace ActiveMQ::Command;
+using namespace ActiveMQ::IO;
+using std::auto_ptr;
+using boost::shared_ptr;
+
+/*
+ *  Marshalling code for Open Wire Format for JournalTopicAck
+ *
+ * NOTE!: This file is autogenerated - do not modify!
+ *        if you need to make a change, please see the Groovy scripts in the
+ *        activemq-core module
+ */
+
+JournalTopicAckMarshaller::JournalTopicAckMarshaller()
+{
+    // no-op
+}
+
+JournalTopicAckMarshaller::~JournalTopicAckMarshaller()
+{
+    // no-op
+}
+
+auto_ptr<IDataStructure> JournalTopicAckMarshaller::createCommand() 
+{
+    return auto_ptr<IDataStructure>(new JournalTopicAck());
+}
+
+char JournalTopicAckMarshaller::getDataStructureType() 
+{
+    return JournalTopicAck::TYPE;
+}
+
+/* 
+ * Un-marshal an object instance from the data input stream
+ */ 
+void
+JournalTopicAckMarshaller::unmarshal(ProtocolFormat& wireFormat, IDataStructure& o, BinaryReader& dataIn, BooleanStream& bs) 
+{
+
+    JournalTopicAck& info = (JournalTopicAck&) o;
+    info.setDestination( shared_ptr<ActiveMQDestination>(static_cast<ActiveMQDestination*>(unmarshalNestedObject(wireFormat, dataIn, bs).release())) );
+    info.setMessageId( shared_ptr<MessageId>(static_cast<MessageId*>(unmarshalNestedObject(wireFormat, dataIn, bs).release())) );
+    info.setMessageSequenceId( unmarshalLong(wireFormat, dataIn, bs) );
+    info.setSubscritionName( unmarshalString(wireFormat, dataIn, bs) );
+    info.setClientId( unmarshalString(wireFormat, dataIn, bs) );
+    info.setTransactionId( shared_ptr<TransactionId>(static_cast<TransactionId*>(unmarshalNestedObject(wireFormat, dataIn, bs).release())) );
+
+}
+
+/*
+ * Write the booleans that this object uses to a BooleanStream
+ */
+size_t
+JournalTopicAckMarshaller::marshal1(ProtocolFormat& wireFormat, const IDataStructure& o, BooleanStream& bs) {
+    JournalTopicAck& info = (JournalTopicAck&) o;
+
+    int rc = 0;
+    rc += marshal1NestedObject(wireFormat, info.getDestination(), bs);
+    rc += marshal1NestedObject(wireFormat, info.getMessageId(), bs);
+    rc += writeLong1(info.getMessageSequenceId(), bs);
+    rc += writeString1(info.getSubscritionName(), bs);
+    rc += writeString1(info.getClientId(), bs);
+    rc += marshal1NestedObject(wireFormat, info.getTransactionId(), bs);
+
+    return rc + 0;
+}
+
+/* 
+ * Write a object instance to data output stream
+ */
+void
+JournalTopicAckMarshaller::marshal2(ProtocolFormat& wireFormat, const IDataStructure& o, BinaryWriter& dataOut, BooleanStream& bs) {
+    // }
+
+
+    JournalTopicAck& info = (JournalTopicAck&) o;
+    marshal2NestedObject(wireFormat, info.getDestination(), dataOut, bs);
+    marshal2NestedObject(wireFormat, info.getMessageId(), dataOut, bs);
+    writeLong2(info.getMessageSequenceId(), dataOut, bs);
+    writeString2(info.getSubscritionName(), dataOut, bs);
+    writeString2(info.getClientId(), dataOut, bs);
+    marshal2NestedObject(wireFormat, info.getTransactionId(), dataOut, bs);
+}

Propchange: incubator/activemq/trunk/amazon/marshal/JournalTopicAckMarshaller.cpp
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/activemq/trunk/amazon/marshal/JournalTopicAckMarshaller.cpp
------------------------------------------------------------------------------
    svn:keywords = Date Author Id Revision HeadURL

Added: incubator/activemq/trunk/amazon/marshal/JournalTopicAckMarshaller.h
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/amazon/marshal/JournalTopicAckMarshaller.h?rev=427057&view=auto
==============================================================================
--- incubator/activemq/trunk/amazon/marshal/JournalTopicAckMarshaller.h (added)
+++ incubator/activemq/trunk/amazon/marshal/JournalTopicAckMarshaller.h Mon Jul 31 02:36:40 2006
@@ -0,0 +1,72 @@
+/*
+  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.
+*/
+
+#ifndef JournalTopicAckMarshaller_h_
+#define JournalTopicAckMarshaller_h_
+
+#include <string>
+#include <memory>
+
+#include "command/IDataStructure.h"
+
+/* auto-generated! */
+/* we could cut this down  - for now include all possible headers */
+#include "command/BrokerId.h"
+#include "command/ConnectionId.h"
+#include "command/ConsumerId.h"
+#include "command/ProducerId.h"
+#include "command/SessionId.h"
+#include "command/BaseCommand.h"
+
+#include "marshal/BinaryReader.h"
+#include "marshal/BinaryWriter.h"
+
+#include "marshal/BaseDataStreamMarshaller.h"
+
+#include "marshal/ProtocolFormat.h"
+
+namespace ActiveMQ {
+  namespace Marshalling {
+
+    class JournalTopicAckMarshaller : public BaseDataStreamMarshaller
+    {
+    public:
+        JournalTopicAckMarshaller();
+        virtual ~JournalTopicAckMarshaller();
+
+        virtual auto_ptr<ActiveMQ::Command::IDataStructure> createCommand();
+        virtual char getDataStructureType();
+        
+        virtual void unmarshal(ProtocolFormat& wireFormat,
+                     ActiveMQ::Command::IDataStructure& o,
+                     ActiveMQ::IO::BinaryReader& dataIn,
+                     ActiveMQ::IO::BooleanStream& bs);
+
+        virtual size_t marshal1(ProtocolFormat& wireFormat, 
+                             const ActiveMQ::Command::IDataStructure& o,
+                             ActiveMQ::IO::BooleanStream& bs);
+
+        virtual void marshal2(ProtocolFormat& wireFormat, 
+                              const ActiveMQ::Command::IDataStructure& o,
+                              ActiveMQ::IO::BinaryWriter& dataOut,
+                              ActiveMQ::IO::BooleanStream& bs);
+    };
+  }
+}
+#endif /*JournalTopicAckMarshaller_h_*/

Propchange: incubator/activemq/trunk/amazon/marshal/JournalTopicAckMarshaller.h
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/activemq/trunk/amazon/marshal/JournalTopicAckMarshaller.h
------------------------------------------------------------------------------
    svn:keywords = Date Author Id Revision HeadURL

Added: incubator/activemq/trunk/amazon/marshal/JournalTraceMarshaller.cpp
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/amazon/marshal/JournalTraceMarshaller.cpp?rev=427057&view=auto
==============================================================================
--- incubator/activemq/trunk/amazon/marshal/JournalTraceMarshaller.cpp (added)
+++ incubator/activemq/trunk/amazon/marshal/JournalTraceMarshaller.cpp Mon Jul 31 02:36:40 2006
@@ -0,0 +1,94 @@
+/*
+  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.
+*/
+
+#include "netinet/in.h"
+#include "marshal/JournalTraceMarshaller.h"
+#include "command/JournalTrace.h"
+#include "boost/shared_ptr.hpp"
+
+using namespace ActiveMQ::Marshalling;
+using namespace ActiveMQ::Command;
+using namespace ActiveMQ::IO;
+using std::auto_ptr;
+using boost::shared_ptr;
+
+/*
+ *  Marshalling code for Open Wire Format for JournalTrace
+ *
+ * NOTE!: This file is autogenerated - do not modify!
+ *        if you need to make a change, please see the Groovy scripts in the
+ *        activemq-core module
+ */
+
+JournalTraceMarshaller::JournalTraceMarshaller()
+{
+    // no-op
+}
+
+JournalTraceMarshaller::~JournalTraceMarshaller()
+{
+    // no-op
+}
+
+auto_ptr<IDataStructure> JournalTraceMarshaller::createCommand() 
+{
+    return auto_ptr<IDataStructure>(new JournalTrace());
+}
+
+char JournalTraceMarshaller::getDataStructureType() 
+{
+    return JournalTrace::TYPE;
+}
+
+/* 
+ * Un-marshal an object instance from the data input stream
+ */ 
+void
+JournalTraceMarshaller::unmarshal(ProtocolFormat& wireFormat, IDataStructure& o, BinaryReader& dataIn, BooleanStream& bs) 
+{
+
+    JournalTrace& info = (JournalTrace&) o;
+    info.setMessage( unmarshalString(wireFormat, dataIn, bs) );
+
+}
+
+/*
+ * Write the booleans that this object uses to a BooleanStream
+ */
+size_t
+JournalTraceMarshaller::marshal1(ProtocolFormat& wireFormat, const IDataStructure& o, BooleanStream& bs) {
+    JournalTrace& info = (JournalTrace&) o;
+
+    int rc = 0;
+    rc += writeString1(info.getMessage(), bs);
+
+    return rc + 0;
+}
+
+/* 
+ * Write a object instance to data output stream
+ */
+void
+JournalTraceMarshaller::marshal2(ProtocolFormat& wireFormat, const IDataStructure& o, BinaryWriter& dataOut, BooleanStream& bs) {
+    // }
+
+
+    JournalTrace& info = (JournalTrace&) o;
+    writeString2(info.getMessage(), dataOut, bs);
+}

Propchange: incubator/activemq/trunk/amazon/marshal/JournalTraceMarshaller.cpp
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/activemq/trunk/amazon/marshal/JournalTraceMarshaller.cpp
------------------------------------------------------------------------------
    svn:keywords = Date Author Id Revision HeadURL

Added: incubator/activemq/trunk/amazon/marshal/JournalTraceMarshaller.h
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/amazon/marshal/JournalTraceMarshaller.h?rev=427057&view=auto
==============================================================================
--- incubator/activemq/trunk/amazon/marshal/JournalTraceMarshaller.h (added)
+++ incubator/activemq/trunk/amazon/marshal/JournalTraceMarshaller.h Mon Jul 31 02:36:40 2006
@@ -0,0 +1,72 @@
+/*
+  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.
+*/
+
+#ifndef JournalTraceMarshaller_h_
+#define JournalTraceMarshaller_h_
+
+#include <string>
+#include <memory>
+
+#include "command/IDataStructure.h"
+
+/* auto-generated! */
+/* we could cut this down  - for now include all possible headers */
+#include "command/BrokerId.h"
+#include "command/ConnectionId.h"
+#include "command/ConsumerId.h"
+#include "command/ProducerId.h"
+#include "command/SessionId.h"
+#include "command/BaseCommand.h"
+
+#include "marshal/BinaryReader.h"
+#include "marshal/BinaryWriter.h"
+
+#include "marshal/BaseDataStreamMarshaller.h"
+
+#include "marshal/ProtocolFormat.h"
+
+namespace ActiveMQ {
+  namespace Marshalling {
+
+    class JournalTraceMarshaller : public BaseDataStreamMarshaller
+    {
+    public:
+        JournalTraceMarshaller();
+        virtual ~JournalTraceMarshaller();
+
+        virtual auto_ptr<ActiveMQ::Command::IDataStructure> createCommand();
+        virtual char getDataStructureType();
+        
+        virtual void unmarshal(ProtocolFormat& wireFormat,
+                     ActiveMQ::Command::IDataStructure& o,
+                     ActiveMQ::IO::BinaryReader& dataIn,
+                     ActiveMQ::IO::BooleanStream& bs);
+
+        virtual size_t marshal1(ProtocolFormat& wireFormat, 
+                             const ActiveMQ::Command::IDataStructure& o,
+                             ActiveMQ::IO::BooleanStream& bs);
+
+        virtual void marshal2(ProtocolFormat& wireFormat, 
+                              const ActiveMQ::Command::IDataStructure& o,
+                              ActiveMQ::IO::BinaryWriter& dataOut,
+                              ActiveMQ::IO::BooleanStream& bs);
+    };
+  }
+}
+#endif /*JournalTraceMarshaller_h_*/

Propchange: incubator/activemq/trunk/amazon/marshal/JournalTraceMarshaller.h
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/activemq/trunk/amazon/marshal/JournalTraceMarshaller.h
------------------------------------------------------------------------------
    svn:keywords = Date Author Id Revision HeadURL

Added: incubator/activemq/trunk/amazon/marshal/JournalTransactionMarshaller.cpp
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/amazon/marshal/JournalTransactionMarshaller.cpp?rev=427057&view=auto
==============================================================================
--- incubator/activemq/trunk/amazon/marshal/JournalTransactionMarshaller.cpp (added)
+++ incubator/activemq/trunk/amazon/marshal/JournalTransactionMarshaller.cpp Mon Jul 31 02:36:40 2006
@@ -0,0 +1,99 @@
+/*
+  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.
+*/
+
+#include "netinet/in.h"
+#include "marshal/JournalTransactionMarshaller.h"
+#include "command/JournalTransaction.h"
+#include "boost/shared_ptr.hpp"
+
+using namespace ActiveMQ::Marshalling;
+using namespace ActiveMQ::Command;
+using namespace ActiveMQ::IO;
+using std::auto_ptr;
+using boost::shared_ptr;
+
+/*
+ *  Marshalling code for Open Wire Format for JournalTransaction
+ *
+ * NOTE!: This file is autogenerated - do not modify!
+ *        if you need to make a change, please see the Groovy scripts in the
+ *        activemq-core module
+ */
+
+JournalTransactionMarshaller::JournalTransactionMarshaller()
+{
+    // no-op
+}
+
+JournalTransactionMarshaller::~JournalTransactionMarshaller()
+{
+    // no-op
+}
+
+auto_ptr<IDataStructure> JournalTransactionMarshaller::createCommand() 
+{
+    return auto_ptr<IDataStructure>(new JournalTransaction());
+}
+
+char JournalTransactionMarshaller::getDataStructureType() 
+{
+    return JournalTransaction::TYPE;
+}
+
+/* 
+ * Un-marshal an object instance from the data input stream
+ */ 
+void
+JournalTransactionMarshaller::unmarshal(ProtocolFormat& wireFormat, IDataStructure& o, BinaryReader& dataIn, BooleanStream& bs) 
+{
+
+    JournalTransaction& info = (JournalTransaction&) o;
+    info.setTransactionId( shared_ptr<TransactionId>(static_cast<TransactionId*>(unmarshalNestedObject(wireFormat, dataIn, bs).release())) );
+    info.setType( dataIn.readByte() );
+    info.setWasPrepared( bs.readBoolean() );
+
+}
+
+/*
+ * Write the booleans that this object uses to a BooleanStream
+ */
+size_t
+JournalTransactionMarshaller::marshal1(ProtocolFormat& wireFormat, const IDataStructure& o, BooleanStream& bs) {
+    JournalTransaction& info = (JournalTransaction&) o;
+
+    int rc = 0;
+    rc += marshal1NestedObject(wireFormat, info.getTransactionId(), bs);
+        bs.writeBoolean(info.getWasPrepared());
+
+    return rc + 1;
+}
+
+/* 
+ * Write a object instance to data output stream
+ */
+void
+JournalTransactionMarshaller::marshal2(ProtocolFormat& wireFormat, const IDataStructure& o, BinaryWriter& dataOut, BooleanStream& bs) {
+    // }
+
+
+    JournalTransaction& info = (JournalTransaction&) o;
+    marshal2NestedObject(wireFormat, info.getTransactionId(), dataOut, bs);
+    dataOut.writeByte(info.getType());
+    bs.readBoolean();
+}

Propchange: incubator/activemq/trunk/amazon/marshal/JournalTransactionMarshaller.cpp
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/activemq/trunk/amazon/marshal/JournalTransactionMarshaller.cpp
------------------------------------------------------------------------------
    svn:keywords = Date Author Id Revision HeadURL

Added: incubator/activemq/trunk/amazon/marshal/JournalTransactionMarshaller.h
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/amazon/marshal/JournalTransactionMarshaller.h?rev=427057&view=auto
==============================================================================
--- incubator/activemq/trunk/amazon/marshal/JournalTransactionMarshaller.h (added)
+++ incubator/activemq/trunk/amazon/marshal/JournalTransactionMarshaller.h Mon Jul 31 02:36:40 2006
@@ -0,0 +1,72 @@
+/*
+  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.
+*/
+
+#ifndef JournalTransactionMarshaller_h_
+#define JournalTransactionMarshaller_h_
+
+#include <string>
+#include <memory>
+
+#include "command/IDataStructure.h"
+
+/* auto-generated! */
+/* we could cut this down  - for now include all possible headers */
+#include "command/BrokerId.h"
+#include "command/ConnectionId.h"
+#include "command/ConsumerId.h"
+#include "command/ProducerId.h"
+#include "command/SessionId.h"
+#include "command/BaseCommand.h"
+
+#include "marshal/BinaryReader.h"
+#include "marshal/BinaryWriter.h"
+
+#include "marshal/BaseDataStreamMarshaller.h"
+
+#include "marshal/ProtocolFormat.h"
+
+namespace ActiveMQ {
+  namespace Marshalling {
+
+    class JournalTransactionMarshaller : public BaseDataStreamMarshaller
+    {
+    public:
+        JournalTransactionMarshaller();
+        virtual ~JournalTransactionMarshaller();
+
+        virtual auto_ptr<ActiveMQ::Command::IDataStructure> createCommand();
+        virtual char getDataStructureType();
+        
+        virtual void unmarshal(ProtocolFormat& wireFormat,
+                     ActiveMQ::Command::IDataStructure& o,
+                     ActiveMQ::IO::BinaryReader& dataIn,
+                     ActiveMQ::IO::BooleanStream& bs);
+
+        virtual size_t marshal1(ProtocolFormat& wireFormat, 
+                             const ActiveMQ::Command::IDataStructure& o,
+                             ActiveMQ::IO::BooleanStream& bs);
+
+        virtual void marshal2(ProtocolFormat& wireFormat, 
+                              const ActiveMQ::Command::IDataStructure& o,
+                              ActiveMQ::IO::BinaryWriter& dataOut,
+                              ActiveMQ::IO::BooleanStream& bs);
+    };
+  }
+}
+#endif /*JournalTransactionMarshaller_h_*/

Propchange: incubator/activemq/trunk/amazon/marshal/JournalTransactionMarshaller.h
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/activemq/trunk/amazon/marshal/JournalTransactionMarshaller.h
------------------------------------------------------------------------------
    svn:keywords = Date Author Id Revision HeadURL

Added: incubator/activemq/trunk/amazon/marshal/KeepAliveInfoMarshaller.cpp
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/amazon/marshal/KeepAliveInfoMarshaller.cpp?rev=427057&view=auto
==============================================================================
--- incubator/activemq/trunk/amazon/marshal/KeepAliveInfoMarshaller.cpp (added)
+++ incubator/activemq/trunk/amazon/marshal/KeepAliveInfoMarshaller.cpp Mon Jul 31 02:36:40 2006
@@ -0,0 +1,91 @@
+/*
+  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.
+*/
+
+#include "netinet/in.h"
+#include "marshal/KeepAliveInfoMarshaller.h"
+#include "command/KeepAliveInfo.h"
+#include "boost/shared_ptr.hpp"
+
+using namespace ActiveMQ::Marshalling;
+using namespace ActiveMQ::Command;
+using namespace ActiveMQ::IO;
+using std::auto_ptr;
+using boost::shared_ptr;
+
+/*
+ *  Marshalling code for Open Wire Format for KeepAliveInfo
+ *
+ * NOTE!: This file is autogenerated - do not modify!
+ *        if you need to make a change, please see the Groovy scripts in the
+ *        activemq-core module
+ */
+
+KeepAliveInfoMarshaller::KeepAliveInfoMarshaller()
+{
+    // no-op
+}
+
+KeepAliveInfoMarshaller::~KeepAliveInfoMarshaller()
+{
+    // no-op
+}
+
+auto_ptr<IDataStructure> KeepAliveInfoMarshaller::createCommand() 
+{
+    return auto_ptr<IDataStructure>(new KeepAliveInfo());
+}
+
+char KeepAliveInfoMarshaller::getDataStructureType() 
+{
+    return KeepAliveInfo::TYPE;
+}
+
+/* 
+ * Un-marshal an object instance from the data input stream
+ */ 
+void
+KeepAliveInfoMarshaller::unmarshal(ProtocolFormat& wireFormat, IDataStructure& o, BinaryReader& dataIn, BooleanStream& bs) 
+{
+    BaseCommandMarshaller::unmarshal(wireFormat, o, dataIn, bs);
+
+    KeepAliveInfo& info = (KeepAliveInfo&) o;
+
+}
+
+/*
+ * Write the booleans that this object uses to a BooleanStream
+ */
+size_t
+KeepAliveInfoMarshaller::marshal1(ProtocolFormat& wireFormat, const IDataStructure& o, BooleanStream& bs) {
+    KeepAliveInfo& info = (KeepAliveInfo&) o;
+
+    int rc = BaseCommandMarshaller::marshal1(wireFormat, info, bs);
+
+    return rc + 0;
+}
+
+/* 
+ * Write a object instance to data output stream
+ */
+void
+KeepAliveInfoMarshaller::marshal2(ProtocolFormat& wireFormat, const IDataStructure& o, BinaryWriter& dataOut, BooleanStream& bs) {
+    // }
+
+    BaseCommandMarshaller::marshal2(wireFormat, o, dataOut, bs);
+}

Propchange: incubator/activemq/trunk/amazon/marshal/KeepAliveInfoMarshaller.cpp
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/activemq/trunk/amazon/marshal/KeepAliveInfoMarshaller.cpp
------------------------------------------------------------------------------
    svn:keywords = Date Author Id Revision HeadURL

Added: incubator/activemq/trunk/amazon/marshal/KeepAliveInfoMarshaller.h
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/amazon/marshal/KeepAliveInfoMarshaller.h?rev=427057&view=auto
==============================================================================
--- incubator/activemq/trunk/amazon/marshal/KeepAliveInfoMarshaller.h (added)
+++ incubator/activemq/trunk/amazon/marshal/KeepAliveInfoMarshaller.h Mon Jul 31 02:36:40 2006
@@ -0,0 +1,72 @@
+/*
+  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.
+*/
+
+#ifndef KeepAliveInfoMarshaller_h_
+#define KeepAliveInfoMarshaller_h_
+
+#include <string>
+#include <memory>
+
+#include "command/IDataStructure.h"
+
+/* auto-generated! */
+/* we could cut this down  - for now include all possible headers */
+#include "command/BrokerId.h"
+#include "command/ConnectionId.h"
+#include "command/ConsumerId.h"
+#include "command/ProducerId.h"
+#include "command/SessionId.h"
+#include "command/BaseCommand.h"
+
+#include "marshal/BinaryReader.h"
+#include "marshal/BinaryWriter.h"
+
+#include "marshal/BaseCommandMarshaller.h"
+
+#include "marshal/ProtocolFormat.h"
+
+namespace ActiveMQ {
+  namespace Marshalling {
+
+    class KeepAliveInfoMarshaller : public BaseCommandMarshaller
+    {
+    public:
+        KeepAliveInfoMarshaller();
+        virtual ~KeepAliveInfoMarshaller();
+
+        virtual auto_ptr<ActiveMQ::Command::IDataStructure> createCommand();
+        virtual char getDataStructureType();
+        
+        virtual void unmarshal(ProtocolFormat& wireFormat,
+                     ActiveMQ::Command::IDataStructure& o,
+                     ActiveMQ::IO::BinaryReader& dataIn,
+                     ActiveMQ::IO::BooleanStream& bs);
+
+        virtual size_t marshal1(ProtocolFormat& wireFormat, 
+                             const ActiveMQ::Command::IDataStructure& o,
+                             ActiveMQ::IO::BooleanStream& bs);
+
+        virtual void marshal2(ProtocolFormat& wireFormat, 
+                              const ActiveMQ::Command::IDataStructure& o,
+                              ActiveMQ::IO::BinaryWriter& dataOut,
+                              ActiveMQ::IO::BooleanStream& bs);
+    };
+  }
+}
+#endif /*KeepAliveInfoMarshaller_h_*/

Propchange: incubator/activemq/trunk/amazon/marshal/KeepAliveInfoMarshaller.h
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/activemq/trunk/amazon/marshal/KeepAliveInfoMarshaller.h
------------------------------------------------------------------------------
    svn:keywords = Date Author Id Revision HeadURL

Added: incubator/activemq/trunk/amazon/marshal/LastPartialCommandMarshaller.cpp
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/amazon/marshal/LastPartialCommandMarshaller.cpp?rev=427057&view=auto
==============================================================================
--- incubator/activemq/trunk/amazon/marshal/LastPartialCommandMarshaller.cpp (added)
+++ incubator/activemq/trunk/amazon/marshal/LastPartialCommandMarshaller.cpp Mon Jul 31 02:36:40 2006
@@ -0,0 +1,91 @@
+/*
+  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.
+*/
+
+#include "netinet/in.h"
+#include "marshal/LastPartialCommandMarshaller.h"
+#include "command/LastPartialCommand.h"
+#include "boost/shared_ptr.hpp"
+
+using namespace ActiveMQ::Marshalling;
+using namespace ActiveMQ::Command;
+using namespace ActiveMQ::IO;
+using std::auto_ptr;
+using boost::shared_ptr;
+
+/*
+ *  Marshalling code for Open Wire Format for LastPartialCommand
+ *
+ * NOTE!: This file is autogenerated - do not modify!
+ *        if you need to make a change, please see the Groovy scripts in the
+ *        activemq-core module
+ */
+
+LastPartialCommandMarshaller::LastPartialCommandMarshaller()
+{
+    // no-op
+}
+
+LastPartialCommandMarshaller::~LastPartialCommandMarshaller()
+{
+    // no-op
+}
+
+auto_ptr<IDataStructure> LastPartialCommandMarshaller::createCommand() 
+{
+    return auto_ptr<IDataStructure>(new LastPartialCommand());
+}
+
+char LastPartialCommandMarshaller::getDataStructureType() 
+{
+    return LastPartialCommand::TYPE;
+}
+
+/* 
+ * Un-marshal an object instance from the data input stream
+ */ 
+void
+LastPartialCommandMarshaller::unmarshal(ProtocolFormat& wireFormat, IDataStructure& o, BinaryReader& dataIn, BooleanStream& bs) 
+{
+    PartialCommandMarshaller::unmarshal(wireFormat, o, dataIn, bs);
+
+    LastPartialCommand& info = (LastPartialCommand&) o;
+
+}
+
+/*
+ * Write the booleans that this object uses to a BooleanStream
+ */
+size_t
+LastPartialCommandMarshaller::marshal1(ProtocolFormat& wireFormat, const IDataStructure& o, BooleanStream& bs) {
+    LastPartialCommand& info = (LastPartialCommand&) o;
+
+    int rc = PartialCommandMarshaller::marshal1(wireFormat, info, bs);
+
+    return rc + 0;
+}
+
+/* 
+ * Write a object instance to data output stream
+ */
+void
+LastPartialCommandMarshaller::marshal2(ProtocolFormat& wireFormat, const IDataStructure& o, BinaryWriter& dataOut, BooleanStream& bs) {
+    // }
+
+    PartialCommandMarshaller::marshal2(wireFormat, o, dataOut, bs);
+}

Propchange: incubator/activemq/trunk/amazon/marshal/LastPartialCommandMarshaller.cpp
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/activemq/trunk/amazon/marshal/LastPartialCommandMarshaller.cpp
------------------------------------------------------------------------------
    svn:keywords = Date Author Id Revision HeadURL

Added: incubator/activemq/trunk/amazon/marshal/LastPartialCommandMarshaller.h
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/amazon/marshal/LastPartialCommandMarshaller.h?rev=427057&view=auto
==============================================================================
--- incubator/activemq/trunk/amazon/marshal/LastPartialCommandMarshaller.h (added)
+++ incubator/activemq/trunk/amazon/marshal/LastPartialCommandMarshaller.h Mon Jul 31 02:36:40 2006
@@ -0,0 +1,72 @@
+/*
+  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.
+*/
+
+#ifndef LastPartialCommandMarshaller_h_
+#define LastPartialCommandMarshaller_h_
+
+#include <string>
+#include <memory>
+
+#include "command/IDataStructure.h"
+
+/* auto-generated! */
+/* we could cut this down  - for now include all possible headers */
+#include "command/BrokerId.h"
+#include "command/ConnectionId.h"
+#include "command/ConsumerId.h"
+#include "command/ProducerId.h"
+#include "command/SessionId.h"
+#include "command/BaseCommand.h"
+
+#include "marshal/BinaryReader.h"
+#include "marshal/BinaryWriter.h"
+
+#include "marshal/PartialCommandMarshaller.h"
+
+#include "marshal/ProtocolFormat.h"
+
+namespace ActiveMQ {
+  namespace Marshalling {
+
+    class LastPartialCommandMarshaller : public PartialCommandMarshaller
+    {
+    public:
+        LastPartialCommandMarshaller();
+        virtual ~LastPartialCommandMarshaller();
+
+        virtual auto_ptr<ActiveMQ::Command::IDataStructure> createCommand();
+        virtual char getDataStructureType();
+        
+        virtual void unmarshal(ProtocolFormat& wireFormat,
+                     ActiveMQ::Command::IDataStructure& o,
+                     ActiveMQ::IO::BinaryReader& dataIn,
+                     ActiveMQ::IO::BooleanStream& bs);
+
+        virtual size_t marshal1(ProtocolFormat& wireFormat, 
+                             const ActiveMQ::Command::IDataStructure& o,
+                             ActiveMQ::IO::BooleanStream& bs);
+
+        virtual void marshal2(ProtocolFormat& wireFormat, 
+                              const ActiveMQ::Command::IDataStructure& o,
+                              ActiveMQ::IO::BinaryWriter& dataOut,
+                              ActiveMQ::IO::BooleanStream& bs);
+    };
+  }
+}
+#endif /*LastPartialCommandMarshaller_h_*/

Propchange: incubator/activemq/trunk/amazon/marshal/LastPartialCommandMarshaller.h
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/activemq/trunk/amazon/marshal/LastPartialCommandMarshaller.h
------------------------------------------------------------------------------
    svn:keywords = Date Author Id Revision HeadURL

Added: incubator/activemq/trunk/amazon/marshal/LocalTransactionIdMarshaller.cpp
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/amazon/marshal/LocalTransactionIdMarshaller.cpp?rev=427057&view=auto
==============================================================================
--- incubator/activemq/trunk/amazon/marshal/LocalTransactionIdMarshaller.cpp (added)
+++ incubator/activemq/trunk/amazon/marshal/LocalTransactionIdMarshaller.cpp Mon Jul 31 02:36:40 2006
@@ -0,0 +1,99 @@
+/*
+  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.
+*/
+
+#include "netinet/in.h"
+#include "marshal/LocalTransactionIdMarshaller.h"
+#include "command/LocalTransactionId.h"
+#include "boost/shared_ptr.hpp"
+
+using namespace ActiveMQ::Marshalling;
+using namespace ActiveMQ::Command;
+using namespace ActiveMQ::IO;
+using std::auto_ptr;
+using boost::shared_ptr;
+
+/*
+ *  Marshalling code for Open Wire Format for LocalTransactionId
+ *
+ * NOTE!: This file is autogenerated - do not modify!
+ *        if you need to make a change, please see the Groovy scripts in the
+ *        activemq-core module
+ */
+
+LocalTransactionIdMarshaller::LocalTransactionIdMarshaller()
+{
+    // no-op
+}
+
+LocalTransactionIdMarshaller::~LocalTransactionIdMarshaller()
+{
+    // no-op
+}
+
+auto_ptr<IDataStructure> LocalTransactionIdMarshaller::createCommand() 
+{
+    return auto_ptr<IDataStructure>(new LocalTransactionId());
+}
+
+char LocalTransactionIdMarshaller::getDataStructureType() 
+{
+    return LocalTransactionId::TYPE;
+}
+
+/* 
+ * Un-marshal an object instance from the data input stream
+ */ 
+void
+LocalTransactionIdMarshaller::unmarshal(ProtocolFormat& wireFormat, IDataStructure& o, BinaryReader& dataIn, BooleanStream& bs) 
+{
+    TransactionIdMarshaller::unmarshal(wireFormat, o, dataIn, bs);
+
+    LocalTransactionId& info = (LocalTransactionId&) o;
+    info.setValue( unmarshalLong(wireFormat, dataIn, bs) );
+    info.setConnectionId( shared_ptr<ConnectionId>(static_cast<ConnectionId*>(unmarshalCachedObject(wireFormat, dataIn, bs).release())) );
+
+}
+
+/*
+ * Write the booleans that this object uses to a BooleanStream
+ */
+size_t
+LocalTransactionIdMarshaller::marshal1(ProtocolFormat& wireFormat, const IDataStructure& o, BooleanStream& bs) {
+    LocalTransactionId& info = (LocalTransactionId&) o;
+
+    int rc = TransactionIdMarshaller::marshal1(wireFormat, info, bs);
+    rc += writeLong1(info.getValue(), bs);
+    rc += marshal1CachedObject(wireFormat, info.getConnectionId(), bs);
+
+    return rc + 0;
+}
+
+/* 
+ * Write a object instance to data output stream
+ */
+void
+LocalTransactionIdMarshaller::marshal2(ProtocolFormat& wireFormat, const IDataStructure& o, BinaryWriter& dataOut, BooleanStream& bs) {
+    // }
+
+    TransactionIdMarshaller::marshal2(wireFormat, o, dataOut, bs);
+
+    LocalTransactionId& info = (LocalTransactionId&) o;
+    writeLong2(info.getValue(), dataOut, bs);
+    marshal2CachedObject(wireFormat, info.getConnectionId(), dataOut, bs);
+}

Propchange: incubator/activemq/trunk/amazon/marshal/LocalTransactionIdMarshaller.cpp
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/activemq/trunk/amazon/marshal/LocalTransactionIdMarshaller.cpp
------------------------------------------------------------------------------
    svn:keywords = Date Author Id Revision HeadURL

Added: incubator/activemq/trunk/amazon/marshal/LocalTransactionIdMarshaller.h
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/amazon/marshal/LocalTransactionIdMarshaller.h?rev=427057&view=auto
==============================================================================
--- incubator/activemq/trunk/amazon/marshal/LocalTransactionIdMarshaller.h (added)
+++ incubator/activemq/trunk/amazon/marshal/LocalTransactionIdMarshaller.h Mon Jul 31 02:36:40 2006
@@ -0,0 +1,72 @@
+/*
+  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.
+*/
+
+#ifndef LocalTransactionIdMarshaller_h_
+#define LocalTransactionIdMarshaller_h_
+
+#include <string>
+#include <memory>
+
+#include "command/IDataStructure.h"
+
+/* auto-generated! */
+/* we could cut this down  - for now include all possible headers */
+#include "command/BrokerId.h"
+#include "command/ConnectionId.h"
+#include "command/ConsumerId.h"
+#include "command/ProducerId.h"
+#include "command/SessionId.h"
+#include "command/BaseCommand.h"
+
+#include "marshal/BinaryReader.h"
+#include "marshal/BinaryWriter.h"
+
+#include "marshal/TransactionIdMarshaller.h"
+
+#include "marshal/ProtocolFormat.h"
+
+namespace ActiveMQ {
+  namespace Marshalling {
+
+    class LocalTransactionIdMarshaller : public TransactionIdMarshaller
+    {
+    public:
+        LocalTransactionIdMarshaller();
+        virtual ~LocalTransactionIdMarshaller();
+
+        virtual auto_ptr<ActiveMQ::Command::IDataStructure> createCommand();
+        virtual char getDataStructureType();
+        
+        virtual void unmarshal(ProtocolFormat& wireFormat,
+                     ActiveMQ::Command::IDataStructure& o,
+                     ActiveMQ::IO::BinaryReader& dataIn,
+                     ActiveMQ::IO::BooleanStream& bs);
+
+        virtual size_t marshal1(ProtocolFormat& wireFormat, 
+                             const ActiveMQ::Command::IDataStructure& o,
+                             ActiveMQ::IO::BooleanStream& bs);
+
+        virtual void marshal2(ProtocolFormat& wireFormat, 
+                              const ActiveMQ::Command::IDataStructure& o,
+                              ActiveMQ::IO::BinaryWriter& dataOut,
+                              ActiveMQ::IO::BooleanStream& bs);
+    };
+  }
+}
+#endif /*LocalTransactionIdMarshaller_h_*/

Propchange: incubator/activemq/trunk/amazon/marshal/LocalTransactionIdMarshaller.h
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/activemq/trunk/amazon/marshal/LocalTransactionIdMarshaller.h
------------------------------------------------------------------------------
    svn:keywords = Date Author Id Revision HeadURL

Added: incubator/activemq/trunk/amazon/marshal/Makefile.am
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/amazon/marshal/Makefile.am?rev=427057&view=auto
==============================================================================
--- incubator/activemq/trunk/amazon/marshal/Makefile.am (added)
+++ incubator/activemq/trunk/amazon/marshal/Makefile.am Mon Jul 31 02:36:40 2006
@@ -0,0 +1,4 @@
+INCLUDES = -I../
+lib_LTLIBRARIES = libamq_marshal.la
+libamq_marshal_la_SOURCES = ActiveMQBytesMessageMarshaller.cpp ActiveMQDestinationMarshaller.cpp ActiveMQMapMessageMarshaller.cpp ActiveMQMessageMarshaller.cpp ActiveMQObjectMessageMarshaller.cpp ActiveMQQueueMarshaller.cpp ActiveMQStreamMessageMarshaller.cpp ActiveMQTempDestinationMarshaller.cpp ActiveMQTempQueueMarshaller.cpp ActiveMQTempTopicMarshaller.cpp ActiveMQTextMessageMarshaller.cpp ActiveMQTopicMarshaller.cpp BaseCommandMarshaller.cpp BrokerIdMarshaller.cpp BrokerInfoMarshaller.cpp ConnectionErrorMarshaller.cpp ConnectionIdMarshaller.cpp ConnectionInfoMarshaller.cpp ConsumerIdMarshaller.cpp ConsumerInfoMarshaller.cpp ControlCommandMarshaller.cpp DataArrayResponseMarshaller.cpp DataResponseMarshaller.cpp DestinationInfoMarshaller.cpp DiscoveryEventMarshaller.cpp ExceptionResponseMarshaller.cpp FlushCommandMarshaller.cpp IntegerResponseMarshaller.cpp JournalQueueAckMarshaller.cpp JournalTopicAckMarshaller.cpp JournalTraceMarshaller.cpp JournalTransactionMarshaller.c
 pp KeepAliveInfoMarshaller.cpp LastPartialCommandMarshaller.cpp LocalTransactionIdMarshaller.cpp MarshallerFactory.cpp MessageAckMarshaller.cpp MessageDispatchMarshaller.cpp MessageDispatchNotificationMarshaller.cpp MessageIdMarshaller.cpp MessageMarshaller.cpp NetworkBridgeFilterMarshaller.cpp PartialCommandMarshaller.cpp ProducerIdMarshaller.cpp ProducerInfoMarshaller.cpp RemoveInfoMarshaller.cpp RemoveSubscriptionInfoMarshaller.cpp ReplayCommandMarshaller.cpp ResponseMarshaller.cpp SessionIdMarshaller.cpp SessionInfoMarshaller.cpp ShutdownInfoMarshaller.cpp SubscriptionInfoMarshaller.cpp TransactionIdMarshaller.cpp TransactionInfoMarshaller.cpp WireFormatInfoMarshaller.cpp XATransactionIdMarshaller.cpp ProtocolFormat.cpp BaseDataStreamMarshaller.cpp BinaryWriter.cpp BufferWriter.cpp BooleanStream.cpp BinaryReader.cpp BufferReader.cpp ConnectionControlMarshaller.cpp ConsumerControlMarshaller.cpp
+include_HEADERS = ActiveMQBytesMessageMarshaller.h ActiveMQDestinationMarshaller.h ActiveMQMapMessageMarshaller.h ActiveMQMessageMarshaller.h ActiveMQObjectMessageMarshaller.h ActiveMQQueueMarshaller.h ActiveMQStreamMessageMarshaller.h ActiveMQTempDestinationMarshaller.h ActiveMQTempQueueMarshaller.h ActiveMQTempTopicMarshaller.h ActiveMQTextMessageMarshaller.h ActiveMQTopicMarshaller.h BaseCommandMarshaller.h BaseDataStreamMarshaller.h BinaryReader.h BinaryWriter.h BooleanStream.h BrokerIdMarshaller.h BrokerInfoMarshaller.h BufferReader.h BufferWriter.h ConnectionControlMarshaller.h ConnectionErrorMarshaller.h ConnectionIdMarshaller.h ConnectionInfoMarshaller.h ConsumerControlMarshaller.h ConsumerIdMarshaller.h ConsumerInfoMarshaller.h ControlCommandMarshaller.h DataArrayResponseMarshaller.h DataResponseMarshaller.h DestinationInfoMarshaller.h DiscoveryEventMarshaller.h ExceptionResponseMarshaller.h FlushCommandMarshaller.h IntegerResponseMarshaller.h IReader.h IWriter.h Jo
 urnalQueueAckMarshaller.h JournalTopicAckMarshaller.h JournalTraceMarshaller.h JournalTransactionMarshaller.h KeepAliveInfoMarshaller.h LastPartialCommandMarshaller.h LocalTransactionIdMarshaller.h MarshallerFactory.h MessageAckMarshaller.h MessageDispatchMarshaller.h MessageDispatchNotificationMarshaller.h MessageIdMarshaller.h MessageMarshaller.h NetworkBridgeFilterMarshaller.h PartialCommandMarshaller.h ProducerIdMarshaller.h ProducerInfoMarshaller.h ProtocolFormat.h RemoveInfoMarshaller.h RemoveSubscriptionInfoMarshaller.h ReplayCommandMarshaller.h ResponseMarshaller.h SessionIdMarshaller.h SessionInfoMarshaller.h ShutdownInfoMarshaller.h SubscriptionInfoMarshaller.h TransactionIdMarshaller.h TransactionInfoMarshaller.h WireFormatInfoMarshaller.h XATransactionIdMarshaller.h