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 [18/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/

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

Added: incubator/activemq/trunk/amazon/marshal/ConsumerInfoMarshaller.cpp
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/amazon/marshal/ConsumerInfoMarshaller.cpp?rev=427057&view=auto
==============================================================================
--- incubator/activemq/trunk/amazon/marshal/ConsumerInfoMarshaller.cpp (added)
+++ incubator/activemq/trunk/amazon/marshal/ConsumerInfoMarshaller.cpp Mon Jul 31 02:36:40 2006
@@ -0,0 +1,145 @@
+/*
+  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/ConsumerInfoMarshaller.h"
+#include "command/ConsumerInfo.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 ConsumerInfo
+ *
+ * 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
+ */
+
+ConsumerInfoMarshaller::ConsumerInfoMarshaller()
+{
+    // no-op
+}
+
+ConsumerInfoMarshaller::~ConsumerInfoMarshaller()
+{
+    // no-op
+}
+
+auto_ptr<IDataStructure> ConsumerInfoMarshaller::createCommand() 
+{
+    return auto_ptr<IDataStructure>(new ConsumerInfo());
+}
+
+char ConsumerInfoMarshaller::getDataStructureType() 
+{
+    return ConsumerInfo::TYPE;
+}
+
+/* 
+ * Un-marshal an object instance from the data input stream
+ */ 
+void
+ConsumerInfoMarshaller::unmarshal(ProtocolFormat& wireFormat, IDataStructure& o, BinaryReader& dataIn, BooleanStream& bs) 
+{
+    BaseCommandMarshaller::unmarshal(wireFormat, o, dataIn, bs);
+
+    ConsumerInfo& info = (ConsumerInfo&) o;
+    info.setConsumerId( shared_ptr<ConsumerId>(static_cast<ConsumerId*>(unmarshalCachedObject(wireFormat, dataIn, bs).release())) );
+    info.setBrowser( bs.readBoolean() );
+    info.setDestination( shared_ptr<ActiveMQDestination>(static_cast<ActiveMQDestination*>(unmarshalCachedObject(wireFormat, dataIn, bs).release())) );
+    info.setPrefetchSize( dataIn.readInt() );
+    info.setMaximumPendingMessageLimit( dataIn.readInt() );
+    info.setDispatchAsync( bs.readBoolean() );
+    info.setSelector( unmarshalString(wireFormat, dataIn, bs) );
+    info.setSubcriptionName( unmarshalString(wireFormat, dataIn, bs) );
+    info.setNoLocal( bs.readBoolean() );
+    info.setExclusive( bs.readBoolean() );
+    info.setRetroactive( bs.readBoolean() );
+    info.setPriority( dataIn.readByte() );
+
+    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 );
+    }
+        info.setNetworkSubscription( bs.readBoolean() );
+    info.setOptimizedAcknowledge( bs.readBoolean() );
+    info.setNoRangeAcks( bs.readBoolean() );
+
+}
+
+/*
+ * Write the booleans that this object uses to a BooleanStream
+ */
+size_t
+ConsumerInfoMarshaller::marshal1(ProtocolFormat& wireFormat, const IDataStructure& o, BooleanStream& bs) {
+    ConsumerInfo& info = (ConsumerInfo&) o;
+
+    int rc = BaseCommandMarshaller::marshal1(wireFormat, info, bs);
+    rc += marshal1CachedObject(wireFormat, info.getConsumerId(), bs);
+    bs.writeBoolean(info.isBrowser());
+    rc += marshal1CachedObject(wireFormat, info.getDestination(), bs);
+            bs.writeBoolean(info.isDispatchAsync());
+    rc += writeString1(info.getSelector(), bs);
+    rc += writeString1(info.getSubcriptionName(), bs);
+    bs.writeBoolean(info.isNoLocal());
+    bs.writeBoolean(info.isExclusive());
+    bs.writeBoolean(info.isRetroactive());
+        rc += marshal1ObjectArray(wireFormat, info.getBrokerPath(), bs);
+        bs.writeBoolean(info.isNetworkSubscription());
+    bs.writeBoolean(info.isOptimizedAcknowledge());
+    bs.writeBoolean(info.isNoRangeAcks());
+
+    return rc + 9;
+}
+
+/* 
+ * Write a object instance to data output stream
+ */
+void
+ConsumerInfoMarshaller::marshal2(ProtocolFormat& wireFormat, const IDataStructure& o, BinaryWriter& dataOut, BooleanStream& bs) {
+    // }
+
+    BaseCommandMarshaller::marshal2(wireFormat, o, dataOut, bs);
+
+    ConsumerInfo& info = (ConsumerInfo&) o;
+    marshal2CachedObject(wireFormat, info.getConsumerId(), dataOut, bs);
+    bs.readBoolean();
+    marshal2CachedObject(wireFormat, info.getDestination(), dataOut, bs);
+    dataOut.writeInt(info.getPrefetchSize());
+    dataOut.writeInt(info.getMaximumPendingMessageLimit());
+    bs.readBoolean();
+    writeString2(info.getSelector(), dataOut, bs);
+    writeString2(info.getSubcriptionName(), dataOut, bs);
+    bs.readBoolean();
+    bs.readBoolean();
+    bs.readBoolean();
+    dataOut.writeByte(info.getPriority());
+    marshal2ObjectArray(wireFormat, info.getBrokerPath(), dataOut, bs);
+        bs.readBoolean();
+    bs.readBoolean();
+    bs.readBoolean();
+}

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

Added: incubator/activemq/trunk/amazon/marshal/DestinationInfoMarshaller.cpp
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/amazon/marshal/DestinationInfoMarshaller.cpp?rev=427057&view=auto
==============================================================================
--- incubator/activemq/trunk/amazon/marshal/DestinationInfoMarshaller.cpp (added)
+++ incubator/activemq/trunk/amazon/marshal/DestinationInfoMarshaller.cpp Mon Jul 31 02:36:40 2006
@@ -0,0 +1,114 @@
+/*
+  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/DestinationInfoMarshaller.h"
+#include "command/DestinationInfo.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 DestinationInfo
+ *
+ * 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
+ */
+
+DestinationInfoMarshaller::DestinationInfoMarshaller()
+{
+    // no-op
+}
+
+DestinationInfoMarshaller::~DestinationInfoMarshaller()
+{
+    // no-op
+}
+
+auto_ptr<IDataStructure> DestinationInfoMarshaller::createCommand() 
+{
+    return auto_ptr<IDataStructure>(new DestinationInfo());
+}
+
+char DestinationInfoMarshaller::getDataStructureType() 
+{
+    return DestinationInfo::TYPE;
+}
+
+/* 
+ * Un-marshal an object instance from the data input stream
+ */ 
+void
+DestinationInfoMarshaller::unmarshal(ProtocolFormat& wireFormat, IDataStructure& o, BinaryReader& dataIn, BooleanStream& bs) 
+{
+    BaseCommandMarshaller::unmarshal(wireFormat, o, dataIn, bs);
+
+    DestinationInfo& info = (DestinationInfo&) o;
+    info.setConnectionId( shared_ptr<ConnectionId>(static_cast<ConnectionId*>(unmarshalCachedObject(wireFormat, dataIn, bs).release())) );
+    info.setDestination( shared_ptr<ActiveMQDestination>(static_cast<ActiveMQDestination*>(unmarshalCachedObject(wireFormat, dataIn, bs).release())) );
+    info.setOperationType( dataIn.readByte() );
+    info.setTimeout( unmarshalLong(wireFormat, dataIn, bs) );
+
+    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
+DestinationInfoMarshaller::marshal1(ProtocolFormat& wireFormat, const IDataStructure& o, BooleanStream& bs) {
+    DestinationInfo& info = (DestinationInfo&) o;
+
+    int rc = BaseCommandMarshaller::marshal1(wireFormat, info, bs);
+    rc += marshal1CachedObject(wireFormat, info.getConnectionId(), bs);
+    rc += marshal1CachedObject(wireFormat, info.getDestination(), bs);
+        rc += writeLong1(info.getTimeout(), bs);
+    rc += marshal1ObjectArray(wireFormat, info.getBrokerPath(), bs);
+
+    return rc + 1;
+}
+
+/* 
+ * Write a object instance to data output stream
+ */
+void
+DestinationInfoMarshaller::marshal2(ProtocolFormat& wireFormat, const IDataStructure& o, BinaryWriter& dataOut, BooleanStream& bs) {
+    // }
+
+    BaseCommandMarshaller::marshal2(wireFormat, o, dataOut, bs);
+
+    DestinationInfo& info = (DestinationInfo&) o;
+    marshal2CachedObject(wireFormat, info.getConnectionId(), dataOut, bs);
+    marshal2CachedObject(wireFormat, info.getDestination(), dataOut, bs);
+    dataOut.writeByte(info.getOperationType());
+    writeLong2(info.getTimeout(), dataOut, bs);
+    marshal2ObjectArray(wireFormat, info.getBrokerPath(), dataOut, bs);
+}

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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