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 [21/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/NetworkBridgeFilterMarshaller.h
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/amazon/marshal/NetworkBridgeFilterMarshaller.h?rev=427057&view=auto
==============================================================================
--- incubator/activemq/trunk/amazon/marshal/NetworkBridgeFilterMarshaller.h (added)
+++ incubator/activemq/trunk/amazon/marshal/NetworkBridgeFilterMarshaller.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 NetworkBridgeFilterMarshaller_h_
+#define NetworkBridgeFilterMarshaller_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 NetworkBridgeFilterMarshaller : public BaseDataStreamMarshaller
+    {
+    public:
+        NetworkBridgeFilterMarshaller();
+        virtual ~NetworkBridgeFilterMarshaller();
+
+        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 /*NetworkBridgeFilterMarshaller_h_*/

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

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

Added: incubator/activemq/trunk/amazon/marshal/PartialCommandMarshaller.cpp
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/amazon/marshal/PartialCommandMarshaller.cpp?rev=427057&view=auto
==============================================================================
--- incubator/activemq/trunk/amazon/marshal/PartialCommandMarshaller.cpp (added)
+++ incubator/activemq/trunk/amazon/marshal/PartialCommandMarshaller.cpp Mon Jul 31 02:36:40 2006
@@ -0,0 +1,100 @@
+/*
+  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/PartialCommandMarshaller.h"
+#include "command/PartialCommand.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 PartialCommand
+ *
+ * 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
+ */
+
+PartialCommandMarshaller::PartialCommandMarshaller()
+{
+    // no-op
+}
+
+PartialCommandMarshaller::~PartialCommandMarshaller()
+{
+    // no-op
+}
+
+auto_ptr<IDataStructure> PartialCommandMarshaller::createCommand() 
+{
+    return auto_ptr<IDataStructure>(new PartialCommand());
+}
+
+char PartialCommandMarshaller::getDataStructureType() 
+{
+    return PartialCommand::TYPE;
+}
+
+/* 
+ * Un-marshal an object instance from the data input stream
+ */ 
+void
+PartialCommandMarshaller::unmarshal(ProtocolFormat& wireFormat, IDataStructure& o, BinaryReader& dataIn, BooleanStream& bs) 
+{
+
+    PartialCommand& info = (PartialCommand&) o;
+    info.setCommandId( dataIn.readInt() );
+    info.setData( unmarshalByteSequence(wireFormat, dataIn, bs) );
+
+}
+
+/*
+ * Write the booleans that this object uses to a BooleanStream
+ */
+size_t
+PartialCommandMarshaller::marshal1(ProtocolFormat& wireFormat, const IDataStructure& o, BooleanStream& bs) {
+    PartialCommand& info = (PartialCommand&) o;
+
+    int rc = 0;
+        bs.writeBoolean(!(info.getData().empty()));
+    rc += info.getData().empty() ? 0 : info.getData().size()+4;
+
+    return rc + 4;
+}
+
+/* 
+ * Write a object instance to data output stream
+ */
+void
+PartialCommandMarshaller::marshal2(ProtocolFormat& wireFormat, const IDataStructure& o, BinaryWriter& dataOut, BooleanStream& bs) {
+    // }
+
+
+    PartialCommand& info = (PartialCommand&) o;
+    dataOut.writeInt(info.getCommandId());
+    if(bs.readBoolean()) {
+       dataOut.writeInt(info.getData().size());
+       dataOut.write(&((info.getData())[0]), info.getData().size());
+    }
+}

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

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

Added: incubator/activemq/trunk/amazon/marshal/PartialCommandMarshaller.h
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/amazon/marshal/PartialCommandMarshaller.h?rev=427057&view=auto
==============================================================================
--- incubator/activemq/trunk/amazon/marshal/PartialCommandMarshaller.h (added)
+++ incubator/activemq/trunk/amazon/marshal/PartialCommandMarshaller.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 PartialCommandMarshaller_h_
+#define PartialCommandMarshaller_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 PartialCommandMarshaller : public BaseDataStreamMarshaller
+    {
+    public:
+        PartialCommandMarshaller();
+        virtual ~PartialCommandMarshaller();
+
+        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 /*PartialCommandMarshaller_h_*/

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

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

Added: incubator/activemq/trunk/amazon/marshal/ProducerIdMarshaller.cpp
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/amazon/marshal/ProducerIdMarshaller.cpp?rev=427057&view=auto
==============================================================================
--- incubator/activemq/trunk/amazon/marshal/ProducerIdMarshaller.cpp (added)
+++ incubator/activemq/trunk/amazon/marshal/ProducerIdMarshaller.cpp Mon Jul 31 02:36:40 2006
@@ -0,0 +1,100 @@
+/*
+  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/ProducerIdMarshaller.h"
+#include "command/ProducerId.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 ProducerId
+ *
+ * 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
+ */
+
+ProducerIdMarshaller::ProducerIdMarshaller()
+{
+    // no-op
+}
+
+ProducerIdMarshaller::~ProducerIdMarshaller()
+{
+    // no-op
+}
+
+auto_ptr<IDataStructure> ProducerIdMarshaller::createCommand() 
+{
+    return auto_ptr<IDataStructure>(new ProducerId());
+}
+
+char ProducerIdMarshaller::getDataStructureType() 
+{
+    return ProducerId::TYPE;
+}
+
+/* 
+ * Un-marshal an object instance from the data input stream
+ */ 
+void
+ProducerIdMarshaller::unmarshal(ProtocolFormat& wireFormat, IDataStructure& o, BinaryReader& dataIn, BooleanStream& bs) 
+{
+
+    ProducerId& info = (ProducerId&) o;
+    info.setConnectionId( unmarshalString(wireFormat, dataIn, bs) );
+    info.setValue( unmarshalLong(wireFormat, dataIn, bs) );
+    info.setSessionId( unmarshalLong(wireFormat, dataIn, bs) );
+
+}
+
+/*
+ * Write the booleans that this object uses to a BooleanStream
+ */
+size_t
+ProducerIdMarshaller::marshal1(ProtocolFormat& wireFormat, const IDataStructure& o, BooleanStream& bs) {
+    ProducerId& info = (ProducerId&) o;
+
+    int rc = 0;
+    rc += writeString1(info.getConnectionId(), bs);
+    rc += writeLong1(info.getValue(), bs);
+    rc += writeLong1(info.getSessionId(), bs);
+
+    return rc + 0;
+}
+
+/* 
+ * Write a object instance to data output stream
+ */
+void
+ProducerIdMarshaller::marshal2(ProtocolFormat& wireFormat, const IDataStructure& o, BinaryWriter& dataOut, BooleanStream& bs) {
+    // }
+
+
+    ProducerId& info = (ProducerId&) o;
+    writeString2(info.getConnectionId(), dataOut, bs);
+    writeLong2(info.getValue(), dataOut, bs);
+    writeLong2(info.getSessionId(), dataOut, bs);
+}

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

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

Added: incubator/activemq/trunk/amazon/marshal/ProducerIdMarshaller.h
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/amazon/marshal/ProducerIdMarshaller.h?rev=427057&view=auto
==============================================================================
--- incubator/activemq/trunk/amazon/marshal/ProducerIdMarshaller.h (added)
+++ incubator/activemq/trunk/amazon/marshal/ProducerIdMarshaller.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 ProducerIdMarshaller_h_
+#define ProducerIdMarshaller_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 ProducerIdMarshaller : public BaseDataStreamMarshaller
+    {
+    public:
+        ProducerIdMarshaller();
+        virtual ~ProducerIdMarshaller();
+
+        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 /*ProducerIdMarshaller_h_*/

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

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

Added: incubator/activemq/trunk/amazon/marshal/ProducerInfoMarshaller.cpp
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/amazon/marshal/ProducerInfoMarshaller.cpp?rev=427057&view=auto
==============================================================================
--- incubator/activemq/trunk/amazon/marshal/ProducerInfoMarshaller.cpp (added)
+++ incubator/activemq/trunk/amazon/marshal/ProducerInfoMarshaller.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/ProducerInfoMarshaller.h"
+#include "command/ProducerInfo.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 ProducerInfo
+ *
+ * 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
+ */
+
+ProducerInfoMarshaller::ProducerInfoMarshaller()
+{
+    // no-op
+}
+
+ProducerInfoMarshaller::~ProducerInfoMarshaller()
+{
+    // no-op
+}
+
+auto_ptr<IDataStructure> ProducerInfoMarshaller::createCommand() 
+{
+    return auto_ptr<IDataStructure>(new ProducerInfo());
+}
+
+char ProducerInfoMarshaller::getDataStructureType() 
+{
+    return ProducerInfo::TYPE;
+}
+
+/* 
+ * Un-marshal an object instance from the data input stream
+ */ 
+void
+ProducerInfoMarshaller::unmarshal(ProtocolFormat& wireFormat, IDataStructure& o, BinaryReader& dataIn, BooleanStream& bs) 
+{
+    BaseCommandMarshaller::unmarshal(wireFormat, o, dataIn, bs);
+
+    ProducerInfo& info = (ProducerInfo&) o;
+    info.setProducerId( shared_ptr<ProducerId>(static_cast<ProducerId*>(unmarshalCachedObject(wireFormat, dataIn, bs).release())) );
+    info.setDestination( shared_ptr<ActiveMQDestination>(static_cast<ActiveMQDestination*>(unmarshalCachedObject(wireFormat, dataIn, bs).release())) );
+
+    if (bs.readBoolean()) {
+        short size = dataIn.readShort();
+        std::vector<shared_ptr<const BrokerId> > value;
+        for( int i=0; i < size; i++ )
+            value.push_back(shared_ptr<BrokerId>(static_cast<BrokerId*>(unmarshalNestedObject(wireFormat,dataIn, bs).release())));
+        info.setBrokerPath( value );
+    }
+
+}
+
+/*
+ * Write the booleans that this object uses to a BooleanStream
+ */
+size_t
+ProducerInfoMarshaller::marshal1(ProtocolFormat& wireFormat, const IDataStructure& o, BooleanStream& bs) {
+    ProducerInfo& info = (ProducerInfo&) o;
+
+    int rc = BaseCommandMarshaller::marshal1(wireFormat, info, bs);
+    rc += marshal1CachedObject(wireFormat, info.getProducerId(), bs);
+    rc += marshal1CachedObject(wireFormat, info.getDestination(), bs);
+    rc += marshal1ObjectArray(wireFormat, info.getBrokerPath(), bs);
+
+    return rc + 0;
+}
+
+/* 
+ * Write a object instance to data output stream
+ */
+void
+ProducerInfoMarshaller::marshal2(ProtocolFormat& wireFormat, const IDataStructure& o, BinaryWriter& dataOut, BooleanStream& bs) {
+    // }
+
+    BaseCommandMarshaller::marshal2(wireFormat, o, dataOut, bs);
+
+    ProducerInfo& info = (ProducerInfo&) o;
+    marshal2CachedObject(wireFormat, info.getProducerId(), dataOut, bs);
+    marshal2CachedObject(wireFormat, info.getDestination(), dataOut, bs);
+    marshal2ObjectArray(wireFormat, info.getBrokerPath(), dataOut, bs);
+}

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

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

Added: incubator/activemq/trunk/amazon/marshal/ProducerInfoMarshaller.h
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/amazon/marshal/ProducerInfoMarshaller.h?rev=427057&view=auto
==============================================================================
--- incubator/activemq/trunk/amazon/marshal/ProducerInfoMarshaller.h (added)
+++ incubator/activemq/trunk/amazon/marshal/ProducerInfoMarshaller.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 ProducerInfoMarshaller_h_
+#define ProducerInfoMarshaller_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 ProducerInfoMarshaller : public BaseCommandMarshaller
+    {
+    public:
+        ProducerInfoMarshaller();
+        virtual ~ProducerInfoMarshaller();
+
+        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 /*ProducerInfoMarshaller_h_*/

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

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

Added: incubator/activemq/trunk/amazon/marshal/ProtocolFormat.cpp
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/amazon/marshal/ProtocolFormat.cpp?rev=427057&view=auto
==============================================================================
--- incubator/activemq/trunk/amazon/marshal/ProtocolFormat.cpp (added)
+++ incubator/activemq/trunk/amazon/marshal/ProtocolFormat.cpp Mon Jul 31 02:36:40 2006
@@ -0,0 +1,51 @@
+/*
+  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 "marshal/ProtocolFormat.h"
+#include "marshal/BaseDataStreamMarshaller.h"
+#include <utility>
+#include <map>
+
+using namespace ActiveMQ::Marshalling;
+using std::pair;
+using std::auto_ptr;
+using std::map;
+
+void
+ProtocolFormat::addMarshaller(auto_ptr<BaseDataStreamMarshaller> m) {
+    BaseDataStreamMarshaller *dm = m.release();
+    marshallers_.insert(pair<int,BaseDataStreamMarshaller *>(dm->getDataStructureType(), dm));
+}
+
+BaseDataStreamMarshaller*
+ProtocolFormat::getMarshaller(int type) const {
+    map<int, BaseDataStreamMarshaller*>::const_iterator i = marshallers_.find(type);
+    if (i == marshallers_.end())
+        return NULL;
+    else
+        return i->second;
+}
+
+ProtocolFormat::~ProtocolFormat() {
+    for (map<int, BaseDataStreamMarshaller*>::iterator i = marshallers_.begin();
+         i != marshallers_.end(); ++i) {
+        delete i->second;
+    }
+}
+

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

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

Added: incubator/activemq/trunk/amazon/marshal/ProtocolFormat.h
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/amazon/marshal/ProtocolFormat.h?rev=427057&view=auto
==============================================================================
--- incubator/activemq/trunk/amazon/marshal/ProtocolFormat.h (added)
+++ incubator/activemq/trunk/amazon/marshal/ProtocolFormat.h Mon Jul 31 02:36:40 2006
@@ -0,0 +1,42 @@
+/*
+  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 ProtocolFormat_hpp_
+#define ProtocolFormat_hpp_
+
+#include "marshal/BaseDataStreamMarshaller.h"
+
+#include <map>
+#include <memory>
+
+namespace ActiveMQ {
+  namespace Marshalling {
+    class ProtocolFormat
+    {
+      public:
+        void addMarshaller(std::auto_ptr<BaseDataStreamMarshaller> marshaller);
+        BaseDataStreamMarshaller *getMarshaller(int type) const;
+        ~ProtocolFormat();
+
+      private:
+        std::map<int, BaseDataStreamMarshaller *> marshallers_;
+    };
+  };
+};
+
+#endif /*ProtocolFormat_hpp_*/

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

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

Added: incubator/activemq/trunk/amazon/marshal/RemoveInfoMarshaller.cpp
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/amazon/marshal/RemoveInfoMarshaller.cpp?rev=427057&view=auto
==============================================================================
--- incubator/activemq/trunk/amazon/marshal/RemoveInfoMarshaller.cpp (added)
+++ incubator/activemq/trunk/amazon/marshal/RemoveInfoMarshaller.cpp Mon Jul 31 02:36:40 2006
@@ -0,0 +1,96 @@
+/*
+  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/RemoveInfoMarshaller.h"
+#include "command/RemoveInfo.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 RemoveInfo
+ *
+ * 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
+ */
+
+RemoveInfoMarshaller::RemoveInfoMarshaller()
+{
+    // no-op
+}
+
+RemoveInfoMarshaller::~RemoveInfoMarshaller()
+{
+    // no-op
+}
+
+auto_ptr<IDataStructure> RemoveInfoMarshaller::createCommand() 
+{
+    return auto_ptr<IDataStructure>(new RemoveInfo());
+}
+
+char RemoveInfoMarshaller::getDataStructureType() 
+{
+    return RemoveInfo::TYPE;
+}
+
+/* 
+ * Un-marshal an object instance from the data input stream
+ */ 
+void
+RemoveInfoMarshaller::unmarshal(ProtocolFormat& wireFormat, IDataStructure& o, BinaryReader& dataIn, BooleanStream& bs) 
+{
+    BaseCommandMarshaller::unmarshal(wireFormat, o, dataIn, bs);
+
+    RemoveInfo& info = (RemoveInfo&) o;
+    info.setObjectId( shared_ptr<IDataStructure>(static_cast<IDataStructure*>(unmarshalCachedObject(wireFormat, dataIn, bs).release())) );
+
+}
+
+/*
+ * Write the booleans that this object uses to a BooleanStream
+ */
+size_t
+RemoveInfoMarshaller::marshal1(ProtocolFormat& wireFormat, const IDataStructure& o, BooleanStream& bs) {
+    RemoveInfo& info = (RemoveInfo&) o;
+
+    int rc = BaseCommandMarshaller::marshal1(wireFormat, info, bs);
+    rc += marshal1CachedObject(wireFormat, info.getObjectId(), bs);
+
+    return rc + 0;
+}
+
+/* 
+ * Write a object instance to data output stream
+ */
+void
+RemoveInfoMarshaller::marshal2(ProtocolFormat& wireFormat, const IDataStructure& o, BinaryWriter& dataOut, BooleanStream& bs) {
+    // }
+
+    BaseCommandMarshaller::marshal2(wireFormat, o, dataOut, bs);
+
+    RemoveInfo& info = (RemoveInfo&) o;
+    marshal2CachedObject(wireFormat, info.getObjectId(), dataOut, bs);
+}

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

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

Added: incubator/activemq/trunk/amazon/marshal/RemoveInfoMarshaller.h
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/amazon/marshal/RemoveInfoMarshaller.h?rev=427057&view=auto
==============================================================================
--- incubator/activemq/trunk/amazon/marshal/RemoveInfoMarshaller.h (added)
+++ incubator/activemq/trunk/amazon/marshal/RemoveInfoMarshaller.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 RemoveInfoMarshaller_h_
+#define RemoveInfoMarshaller_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 RemoveInfoMarshaller : public BaseCommandMarshaller
+    {
+    public:
+        RemoveInfoMarshaller();
+        virtual ~RemoveInfoMarshaller();
+
+        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 /*RemoveInfoMarshaller_h_*/

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

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

Added: incubator/activemq/trunk/amazon/marshal/RemoveSubscriptionInfoMarshaller.cpp
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/amazon/marshal/RemoveSubscriptionInfoMarshaller.cpp?rev=427057&view=auto
==============================================================================
--- incubator/activemq/trunk/amazon/marshal/RemoveSubscriptionInfoMarshaller.cpp (added)
+++ incubator/activemq/trunk/amazon/marshal/RemoveSubscriptionInfoMarshaller.cpp Mon Jul 31 02:36:40 2006
@@ -0,0 +1,102 @@
+/*
+  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/RemoveSubscriptionInfoMarshaller.h"
+#include "command/RemoveSubscriptionInfo.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 RemoveSubscriptionInfo
+ *
+ * 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
+ */
+
+RemoveSubscriptionInfoMarshaller::RemoveSubscriptionInfoMarshaller()
+{
+    // no-op
+}
+
+RemoveSubscriptionInfoMarshaller::~RemoveSubscriptionInfoMarshaller()
+{
+    // no-op
+}
+
+auto_ptr<IDataStructure> RemoveSubscriptionInfoMarshaller::createCommand() 
+{
+    return auto_ptr<IDataStructure>(new RemoveSubscriptionInfo());
+}
+
+char RemoveSubscriptionInfoMarshaller::getDataStructureType() 
+{
+    return RemoveSubscriptionInfo::TYPE;
+}
+
+/* 
+ * Un-marshal an object instance from the data input stream
+ */ 
+void
+RemoveSubscriptionInfoMarshaller::unmarshal(ProtocolFormat& wireFormat, IDataStructure& o, BinaryReader& dataIn, BooleanStream& bs) 
+{
+    BaseCommandMarshaller::unmarshal(wireFormat, o, dataIn, bs);
+
+    RemoveSubscriptionInfo& info = (RemoveSubscriptionInfo&) o;
+    info.setConnectionId( shared_ptr<ConnectionId>(static_cast<ConnectionId*>(unmarshalCachedObject(wireFormat, dataIn, bs).release())) );
+    info.setSubcriptionName( unmarshalString(wireFormat, dataIn, bs) );
+    info.setClientId( unmarshalString(wireFormat, dataIn, bs) );
+
+}
+
+/*
+ * Write the booleans that this object uses to a BooleanStream
+ */
+size_t
+RemoveSubscriptionInfoMarshaller::marshal1(ProtocolFormat& wireFormat, const IDataStructure& o, BooleanStream& bs) {
+    RemoveSubscriptionInfo& info = (RemoveSubscriptionInfo&) o;
+
+    int rc = BaseCommandMarshaller::marshal1(wireFormat, info, bs);
+    rc += marshal1CachedObject(wireFormat, info.getConnectionId(), bs);
+    rc += writeString1(info.getSubcriptionName(), bs);
+    rc += writeString1(info.getClientId(), bs);
+
+    return rc + 0;
+}
+
+/* 
+ * Write a object instance to data output stream
+ */
+void
+RemoveSubscriptionInfoMarshaller::marshal2(ProtocolFormat& wireFormat, const IDataStructure& o, BinaryWriter& dataOut, BooleanStream& bs) {
+    // }
+
+    BaseCommandMarshaller::marshal2(wireFormat, o, dataOut, bs);
+
+    RemoveSubscriptionInfo& info = (RemoveSubscriptionInfo&) o;
+    marshal2CachedObject(wireFormat, info.getConnectionId(), dataOut, bs);
+    writeString2(info.getSubcriptionName(), dataOut, bs);
+    writeString2(info.getClientId(), dataOut, bs);
+}

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

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

Added: incubator/activemq/trunk/amazon/marshal/RemoveSubscriptionInfoMarshaller.h
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/amazon/marshal/RemoveSubscriptionInfoMarshaller.h?rev=427057&view=auto
==============================================================================
--- incubator/activemq/trunk/amazon/marshal/RemoveSubscriptionInfoMarshaller.h (added)
+++ incubator/activemq/trunk/amazon/marshal/RemoveSubscriptionInfoMarshaller.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 RemoveSubscriptionInfoMarshaller_h_
+#define RemoveSubscriptionInfoMarshaller_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 RemoveSubscriptionInfoMarshaller : public BaseCommandMarshaller
+    {
+    public:
+        RemoveSubscriptionInfoMarshaller();
+        virtual ~RemoveSubscriptionInfoMarshaller();
+
+        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 /*RemoveSubscriptionInfoMarshaller_h_*/

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

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

Added: incubator/activemq/trunk/amazon/marshal/ReplayCommandMarshaller.cpp
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/amazon/marshal/ReplayCommandMarshaller.cpp?rev=427057&view=auto
==============================================================================
--- incubator/activemq/trunk/amazon/marshal/ReplayCommandMarshaller.cpp (added)
+++ incubator/activemq/trunk/amazon/marshal/ReplayCommandMarshaller.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/ReplayCommandMarshaller.h"
+#include "command/ReplayCommand.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 ReplayCommand
+ *
+ * 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
+ */
+
+ReplayCommandMarshaller::ReplayCommandMarshaller()
+{
+    // no-op
+}
+
+ReplayCommandMarshaller::~ReplayCommandMarshaller()
+{
+    // no-op
+}
+
+auto_ptr<IDataStructure> ReplayCommandMarshaller::createCommand() 
+{
+    return auto_ptr<IDataStructure>(new ReplayCommand());
+}
+
+char ReplayCommandMarshaller::getDataStructureType() 
+{
+    return ReplayCommand::TYPE;
+}
+
+/* 
+ * Un-marshal an object instance from the data input stream
+ */ 
+void
+ReplayCommandMarshaller::unmarshal(ProtocolFormat& wireFormat, IDataStructure& o, BinaryReader& dataIn, BooleanStream& bs) 
+{
+    BaseCommandMarshaller::unmarshal(wireFormat, o, dataIn, bs);
+
+    ReplayCommand& info = (ReplayCommand&) o;
+    info.setFirstNakNumber( dataIn.readInt() );
+    info.setLastNakNumber( dataIn.readInt() );
+
+}
+
+/*
+ * Write the booleans that this object uses to a BooleanStream
+ */
+size_t
+ReplayCommandMarshaller::marshal1(ProtocolFormat& wireFormat, const IDataStructure& o, BooleanStream& bs) {
+    ReplayCommand& info = (ReplayCommand&) o;
+
+    int rc = BaseCommandMarshaller::marshal1(wireFormat, info, bs);
+        
+    return rc + 8;
+}
+
+/* 
+ * Write a object instance to data output stream
+ */
+void
+ReplayCommandMarshaller::marshal2(ProtocolFormat& wireFormat, const IDataStructure& o, BinaryWriter& dataOut, BooleanStream& bs) {
+    // }
+
+    BaseCommandMarshaller::marshal2(wireFormat, o, dataOut, bs);
+
+    ReplayCommand& info = (ReplayCommand&) o;
+    dataOut.writeInt(info.getFirstNakNumber());
+    dataOut.writeInt(info.getLastNakNumber());
+}

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

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

Added: incubator/activemq/trunk/amazon/marshal/ReplayCommandMarshaller.h
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/amazon/marshal/ReplayCommandMarshaller.h?rev=427057&view=auto
==============================================================================
--- incubator/activemq/trunk/amazon/marshal/ReplayCommandMarshaller.h (added)
+++ incubator/activemq/trunk/amazon/marshal/ReplayCommandMarshaller.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 ReplayCommandMarshaller_h_
+#define ReplayCommandMarshaller_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 ReplayCommandMarshaller : public BaseCommandMarshaller
+    {
+    public:
+        ReplayCommandMarshaller();
+        virtual ~ReplayCommandMarshaller();
+
+        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 /*ReplayCommandMarshaller_h_*/

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

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

Added: incubator/activemq/trunk/amazon/marshal/ResponseMarshaller.cpp
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/amazon/marshal/ResponseMarshaller.cpp?rev=427057&view=auto
==============================================================================
--- incubator/activemq/trunk/amazon/marshal/ResponseMarshaller.cpp (added)
+++ incubator/activemq/trunk/amazon/marshal/ResponseMarshaller.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/ResponseMarshaller.h"
+#include "command/Response.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 Response
+ *
+ * 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
+ */
+
+ResponseMarshaller::ResponseMarshaller()
+{
+    // no-op
+}
+
+ResponseMarshaller::~ResponseMarshaller()
+{
+    // no-op
+}
+
+auto_ptr<IDataStructure> ResponseMarshaller::createCommand() 
+{
+    return auto_ptr<IDataStructure>(new Response());
+}
+
+char ResponseMarshaller::getDataStructureType() 
+{
+    return Response::TYPE;
+}
+
+/* 
+ * Un-marshal an object instance from the data input stream
+ */ 
+void
+ResponseMarshaller::unmarshal(ProtocolFormat& wireFormat, IDataStructure& o, BinaryReader& dataIn, BooleanStream& bs) 
+{
+    BaseCommandMarshaller::unmarshal(wireFormat, o, dataIn, bs);
+
+    Response& info = (Response&) o;
+    info.setCorrelationId( dataIn.readInt() );
+
+}
+
+/*
+ * Write the booleans that this object uses to a BooleanStream
+ */
+size_t
+ResponseMarshaller::marshal1(ProtocolFormat& wireFormat, const IDataStructure& o, BooleanStream& bs) {
+    Response& info = (Response&) o;
+
+    int rc = BaseCommandMarshaller::marshal1(wireFormat, info, bs);
+    
+    return rc + 4;
+}
+
+/* 
+ * Write a object instance to data output stream
+ */
+void
+ResponseMarshaller::marshal2(ProtocolFormat& wireFormat, const IDataStructure& o, BinaryWriter& dataOut, BooleanStream& bs) {
+    // }
+
+    BaseCommandMarshaller::marshal2(wireFormat, o, dataOut, bs);
+
+    Response& info = (Response&) o;
+    dataOut.writeInt(info.getCorrelationId());
+}

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

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

Added: incubator/activemq/trunk/amazon/marshal/ResponseMarshaller.h
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/amazon/marshal/ResponseMarshaller.h?rev=427057&view=auto
==============================================================================
--- incubator/activemq/trunk/amazon/marshal/ResponseMarshaller.h (added)
+++ incubator/activemq/trunk/amazon/marshal/ResponseMarshaller.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 ResponseMarshaller_h_
+#define ResponseMarshaller_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 ResponseMarshaller : public BaseCommandMarshaller
+    {
+    public:
+        ResponseMarshaller();
+        virtual ~ResponseMarshaller();
+
+        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 /*ResponseMarshaller_h_*/

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

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

Added: incubator/activemq/trunk/amazon/marshal/SessionIdMarshaller.cpp
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/amazon/marshal/SessionIdMarshaller.cpp?rev=427057&view=auto
==============================================================================
--- incubator/activemq/trunk/amazon/marshal/SessionIdMarshaller.cpp (added)
+++ incubator/activemq/trunk/amazon/marshal/SessionIdMarshaller.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/SessionIdMarshaller.h"
+#include "command/SessionId.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 SessionId
+ *
+ * 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
+ */
+
+SessionIdMarshaller::SessionIdMarshaller()
+{
+    // no-op
+}
+
+SessionIdMarshaller::~SessionIdMarshaller()
+{
+    // no-op
+}
+
+auto_ptr<IDataStructure> SessionIdMarshaller::createCommand() 
+{
+    return auto_ptr<IDataStructure>(new SessionId());
+}
+
+char SessionIdMarshaller::getDataStructureType() 
+{
+    return SessionId::TYPE;
+}
+
+/* 
+ * Un-marshal an object instance from the data input stream
+ */ 
+void
+SessionIdMarshaller::unmarshal(ProtocolFormat& wireFormat, IDataStructure& o, BinaryReader& dataIn, BooleanStream& bs) 
+{
+
+    SessionId& info = (SessionId&) o;
+    info.setConnectionId( unmarshalString(wireFormat, dataIn, bs) );
+    info.setValue( unmarshalLong(wireFormat, dataIn, bs) );
+
+}
+
+/*
+ * Write the booleans that this object uses to a BooleanStream
+ */
+size_t
+SessionIdMarshaller::marshal1(ProtocolFormat& wireFormat, const IDataStructure& o, BooleanStream& bs) {
+    SessionId& info = (SessionId&) o;
+
+    int rc = 0;
+    rc += writeString1(info.getConnectionId(), bs);
+    rc += writeLong1(info.getValue(), bs);
+
+    return rc + 0;
+}
+
+/* 
+ * Write a object instance to data output stream
+ */
+void
+SessionIdMarshaller::marshal2(ProtocolFormat& wireFormat, const IDataStructure& o, BinaryWriter& dataOut, BooleanStream& bs) {
+    // }
+
+
+    SessionId& info = (SessionId&) o;
+    writeString2(info.getConnectionId(), dataOut, bs);
+    writeLong2(info.getValue(), dataOut, bs);
+}

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

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

Added: incubator/activemq/trunk/amazon/marshal/SessionIdMarshaller.h
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/amazon/marshal/SessionIdMarshaller.h?rev=427057&view=auto
==============================================================================
--- incubator/activemq/trunk/amazon/marshal/SessionIdMarshaller.h (added)
+++ incubator/activemq/trunk/amazon/marshal/SessionIdMarshaller.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 SessionIdMarshaller_h_
+#define SessionIdMarshaller_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 SessionIdMarshaller : public BaseDataStreamMarshaller
+    {
+    public:
+        SessionIdMarshaller();
+        virtual ~SessionIdMarshaller();
+
+        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 /*SessionIdMarshaller_h_*/

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

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

Added: incubator/activemq/trunk/amazon/marshal/SessionInfoMarshaller.cpp
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/amazon/marshal/SessionInfoMarshaller.cpp?rev=427057&view=auto
==============================================================================
--- incubator/activemq/trunk/amazon/marshal/SessionInfoMarshaller.cpp (added)
+++ incubator/activemq/trunk/amazon/marshal/SessionInfoMarshaller.cpp Mon Jul 31 02:36:40 2006
@@ -0,0 +1,96 @@
+/*
+  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/SessionInfoMarshaller.h"
+#include "command/SessionInfo.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 SessionInfo
+ *
+ * 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
+ */
+
+SessionInfoMarshaller::SessionInfoMarshaller()
+{
+    // no-op
+}
+
+SessionInfoMarshaller::~SessionInfoMarshaller()
+{
+    // no-op
+}
+
+auto_ptr<IDataStructure> SessionInfoMarshaller::createCommand() 
+{
+    return auto_ptr<IDataStructure>(new SessionInfo());
+}
+
+char SessionInfoMarshaller::getDataStructureType() 
+{
+    return SessionInfo::TYPE;
+}
+
+/* 
+ * Un-marshal an object instance from the data input stream
+ */ 
+void
+SessionInfoMarshaller::unmarshal(ProtocolFormat& wireFormat, IDataStructure& o, BinaryReader& dataIn, BooleanStream& bs) 
+{
+    BaseCommandMarshaller::unmarshal(wireFormat, o, dataIn, bs);
+
+    SessionInfo& info = (SessionInfo&) o;
+    info.setSessionId( shared_ptr<SessionId>(static_cast<SessionId*>(unmarshalCachedObject(wireFormat, dataIn, bs).release())) );
+
+}
+
+/*
+ * Write the booleans that this object uses to a BooleanStream
+ */
+size_t
+SessionInfoMarshaller::marshal1(ProtocolFormat& wireFormat, const IDataStructure& o, BooleanStream& bs) {
+    SessionInfo& info = (SessionInfo&) o;
+
+    int rc = BaseCommandMarshaller::marshal1(wireFormat, info, bs);
+    rc += marshal1CachedObject(wireFormat, info.getSessionId(), bs);
+
+    return rc + 0;
+}
+
+/* 
+ * Write a object instance to data output stream
+ */
+void
+SessionInfoMarshaller::marshal2(ProtocolFormat& wireFormat, const IDataStructure& o, BinaryWriter& dataOut, BooleanStream& bs) {
+    // }
+
+    BaseCommandMarshaller::marshal2(wireFormat, o, dataOut, bs);
+
+    SessionInfo& info = (SessionInfo&) o;
+    marshal2CachedObject(wireFormat, info.getSessionId(), dataOut, bs);
+}

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

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

Added: incubator/activemq/trunk/amazon/marshal/SessionInfoMarshaller.h
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/amazon/marshal/SessionInfoMarshaller.h?rev=427057&view=auto
==============================================================================
--- incubator/activemq/trunk/amazon/marshal/SessionInfoMarshaller.h (added)
+++ incubator/activemq/trunk/amazon/marshal/SessionInfoMarshaller.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 SessionInfoMarshaller_h_
+#define SessionInfoMarshaller_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 SessionInfoMarshaller : public BaseCommandMarshaller
+    {
+    public:
+        SessionInfoMarshaller();
+        virtual ~SessionInfoMarshaller();
+
+        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 /*SessionInfoMarshaller_h_*/

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

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

Added: incubator/activemq/trunk/amazon/marshal/ShutdownInfoMarshaller.cpp
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/amazon/marshal/ShutdownInfoMarshaller.cpp?rev=427057&view=auto
==============================================================================
--- incubator/activemq/trunk/amazon/marshal/ShutdownInfoMarshaller.cpp (added)
+++ incubator/activemq/trunk/amazon/marshal/ShutdownInfoMarshaller.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/ShutdownInfoMarshaller.h"
+#include "command/ShutdownInfo.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 ShutdownInfo
+ *
+ * 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
+ */
+
+ShutdownInfoMarshaller::ShutdownInfoMarshaller()
+{
+    // no-op
+}
+
+ShutdownInfoMarshaller::~ShutdownInfoMarshaller()
+{
+    // no-op
+}
+
+auto_ptr<IDataStructure> ShutdownInfoMarshaller::createCommand() 
+{
+    return auto_ptr<IDataStructure>(new ShutdownInfo());
+}
+
+char ShutdownInfoMarshaller::getDataStructureType() 
+{
+    return ShutdownInfo::TYPE;
+}
+
+/* 
+ * Un-marshal an object instance from the data input stream
+ */ 
+void
+ShutdownInfoMarshaller::unmarshal(ProtocolFormat& wireFormat, IDataStructure& o, BinaryReader& dataIn, BooleanStream& bs) 
+{
+    BaseCommandMarshaller::unmarshal(wireFormat, o, dataIn, bs);
+
+    ShutdownInfo& info = (ShutdownInfo&) o;
+
+}
+
+/*
+ * Write the booleans that this object uses to a BooleanStream
+ */
+size_t
+ShutdownInfoMarshaller::marshal1(ProtocolFormat& wireFormat, const IDataStructure& o, BooleanStream& bs) {
+    ShutdownInfo& info = (ShutdownInfo&) o;
+
+    int rc = BaseCommandMarshaller::marshal1(wireFormat, info, bs);
+
+    return rc + 0;
+}
+
+/* 
+ * Write a object instance to data output stream
+ */
+void
+ShutdownInfoMarshaller::marshal2(ProtocolFormat& wireFormat, const IDataStructure& o, BinaryWriter& dataOut, BooleanStream& bs) {
+    // }
+
+    BaseCommandMarshaller::marshal2(wireFormat, o, dataOut, bs);
+}

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

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

Added: incubator/activemq/trunk/amazon/marshal/ShutdownInfoMarshaller.h
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/amazon/marshal/ShutdownInfoMarshaller.h?rev=427057&view=auto
==============================================================================
--- incubator/activemq/trunk/amazon/marshal/ShutdownInfoMarshaller.h (added)
+++ incubator/activemq/trunk/amazon/marshal/ShutdownInfoMarshaller.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 ShutdownInfoMarshaller_h_
+#define ShutdownInfoMarshaller_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 ShutdownInfoMarshaller : public BaseCommandMarshaller
+    {
+    public:
+        ShutdownInfoMarshaller();
+        virtual ~ShutdownInfoMarshaller();
+
+        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 /*ShutdownInfoMarshaller_h_*/

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

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

Added: incubator/activemq/trunk/amazon/marshal/SubscriptionInfoMarshaller.cpp
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/amazon/marshal/SubscriptionInfoMarshaller.cpp?rev=427057&view=auto
==============================================================================
--- incubator/activemq/trunk/amazon/marshal/SubscriptionInfoMarshaller.cpp (added)
+++ incubator/activemq/trunk/amazon/marshal/SubscriptionInfoMarshaller.cpp Mon Jul 31 02:36:40 2006
@@ -0,0 +1,103 @@
+/*
+  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/SubscriptionInfoMarshaller.h"
+#include "command/SubscriptionInfo.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 SubscriptionInfo
+ *
+ * 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
+ */
+
+SubscriptionInfoMarshaller::SubscriptionInfoMarshaller()
+{
+    // no-op
+}
+
+SubscriptionInfoMarshaller::~SubscriptionInfoMarshaller()
+{
+    // no-op
+}
+
+auto_ptr<IDataStructure> SubscriptionInfoMarshaller::createCommand() 
+{
+    return auto_ptr<IDataStructure>(new SubscriptionInfo());
+}
+
+char SubscriptionInfoMarshaller::getDataStructureType() 
+{
+    return SubscriptionInfo::TYPE;
+}
+
+/* 
+ * Un-marshal an object instance from the data input stream
+ */ 
+void
+SubscriptionInfoMarshaller::unmarshal(ProtocolFormat& wireFormat, IDataStructure& o, BinaryReader& dataIn, BooleanStream& bs) 
+{
+
+    SubscriptionInfo& info = (SubscriptionInfo&) o;
+    info.setClientId( unmarshalString(wireFormat, dataIn, bs) );
+    info.setDestination( shared_ptr<ActiveMQDestination>(static_cast<ActiveMQDestination*>(unmarshalCachedObject(wireFormat, dataIn, bs).release())) );
+    info.setSelector( unmarshalString(wireFormat, dataIn, bs) );
+    info.setSubcriptionName( unmarshalString(wireFormat, dataIn, bs) );
+
+}
+
+/*
+ * Write the booleans that this object uses to a BooleanStream
+ */
+size_t
+SubscriptionInfoMarshaller::marshal1(ProtocolFormat& wireFormat, const IDataStructure& o, BooleanStream& bs) {
+    SubscriptionInfo& info = (SubscriptionInfo&) o;
+
+    int rc = 0;
+    rc += writeString1(info.getClientId(), bs);
+    rc += marshal1CachedObject(wireFormat, info.getDestination(), bs);
+    rc += writeString1(info.getSelector(), bs);
+    rc += writeString1(info.getSubcriptionName(), bs);
+
+    return rc + 0;
+}
+
+/* 
+ * Write a object instance to data output stream
+ */
+void
+SubscriptionInfoMarshaller::marshal2(ProtocolFormat& wireFormat, const IDataStructure& o, BinaryWriter& dataOut, BooleanStream& bs) {
+    // }
+
+
+    SubscriptionInfo& info = (SubscriptionInfo&) o;
+    writeString2(info.getClientId(), dataOut, bs);
+    marshal2CachedObject(wireFormat, info.getDestination(), dataOut, bs);
+    writeString2(info.getSelector(), dataOut, bs);
+    writeString2(info.getSubcriptionName(), dataOut, bs);
+}

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

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

Added: incubator/activemq/trunk/amazon/marshal/SubscriptionInfoMarshaller.h
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/amazon/marshal/SubscriptionInfoMarshaller.h?rev=427057&view=auto
==============================================================================
--- incubator/activemq/trunk/amazon/marshal/SubscriptionInfoMarshaller.h (added)
+++ incubator/activemq/trunk/amazon/marshal/SubscriptionInfoMarshaller.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 SubscriptionInfoMarshaller_h_
+#define SubscriptionInfoMarshaller_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 SubscriptionInfoMarshaller : public BaseDataStreamMarshaller
+    {
+    public:
+        SubscriptionInfoMarshaller();
+        virtual ~SubscriptionInfoMarshaller();
+
+        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 /*SubscriptionInfoMarshaller_h_*/

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

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