You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@activemq.apache.org by ch...@apache.org on 2006/03/07 03:33:12 UTC

svn commit: r383749 [13/13] - in /incubator/activemq/trunk: activemq-core/ activemq-core/src/gram/java/org/apache/activemq/openwire/tool/ activemq-core/src/gram/script/ activemq-core/src/main/java/org/apache/activemq/command/ activemq-core/src/main/jav...

Modified: incubator/activemq/trunk/openwire-cpp/src/marshal/MessageIdMarshaller.hpp
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/openwire-cpp/src/marshal/MessageIdMarshaller.hpp?rev=383749&r1=383748&r2=383749&view=diff
==============================================================================
--- incubator/activemq/trunk/openwire-cpp/src/marshal/MessageIdMarshaller.hpp (original)
+++ incubator/activemq/trunk/openwire-cpp/src/marshal/MessageIdMarshaller.hpp Mon Mar  6 18:32:50 2006
@@ -1,71 +1 @@
-/*
-* Copyright 2006 The Apache Software Foundation or its licensors, as
-* applicable.
-*
-* Licensed under the Apache License, Version 2.0 (the "License");
-* you may not use this file except in compliance with the License.
-* You may obtain a copy of the License at
-*
-*     http://www.apache.org/licenses/LICENSE-2.0
-*
-* Unless required by applicable law or agreed to in writing, software
-* distributed under the License is distributed on an "AS IS" BASIS,
-* WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-* See the License for the specific language governing permissions and
-* limitations under the License.
-*/
-#ifndef MessageIdMarshaller_hpp_
-#define MessageIdMarshaller_hpp_
-
-#include <string>
-
-#include "command/DataStructure.hpp"
-
-/* we could cut this down  - for now include all possible headers */
-#include "command/BrokerId.hpp"
-#include "command/ConnectionId.hpp"
-#include "command/ConsumerId.hpp"
-#include "command/ProducerId.hpp"
-#include "command/SessionId.hpp"
-
-#include "io/BinaryReader.hpp"
-#include "io/BinaryWriter.hpp"
-
-#include "command/BaseDataStreamMarshaller.hpp"
-#include "util/ifr/p.hpp"
-
-namespace apache
-{
-  namespace activemq
-  {
-    namespace client
-    {
-      namespace marshal
-      {
-        using namespace ifr ;
-        using namespace apache::activemq::client::command;
-        using namespace apache::activemq::client::io;
-
-/*
- *
- */
-class MessageIdMarshaller : public BaseDataStreamMarshaller
-{
-public:
-    MessageIdMarshaller() ;
-    virtual ~MessageIdMarshaller() ;
-
-    virtual DataStructure* createCommand() ;
-    virtual byte getDataStructureType() ;
-    
-    virtual void unmarshal(OpenWireFormat& wireFormat, Object o, BinaryReader& dataIn, BooleanStream& bs) ;
-    virtual int marshal1(OpenWireFormat& wireFormat, Object& o, BooleanStream& bs) ;
-    virtual void marshal2(OpenWireFormat& wireFormat, Object& o, BinaryWriter& dataOut, BooleanStream& bs) ;
-} ;
-
-/* namespace */
-     }
-    }
-  }
-}
-#endif /*MessageIdMarshaller_hpp_*/
+/*
* Copyright 2006 The Apache Software Foundation or its licensors, as
* applicable.
*
* Licensed under the Apache License, Version 2.0 (the "License");
* you may not use this file except in compliance with the License.
* You may obtain a copy of the License at
*
*     http://www.apache.org/licenses/LICENSE-2.0
*
* Unless required by applicable law or agreed to in writing, software
* distributed under the License is distributed on an "AS IS" BASIS,
* WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
* See the License for the specific language governing permissions and
* limitations under the License.
*/
#ifndef MessageIdMarshaller_hpp_
#define MessageIdMarshaller_hpp_

#include <string>

#include "command/DataStructure.hpp"

/* we could cut this down  - for now include all possible headers */
#include "command/BrokerId.hpp"
#include "command/ConnectionId.hpp"
#include "command/ConsumerId.hpp"
#include "command/ProducerId.hpp"
#include "command/Session
 Id.hpp"

#include "io/BinaryReader.hpp"
#include "io/BinaryWriter.hpp"

#include "command/BaseDataStreamMarshaller.hpp"
#include "util/ifr/p.hpp"

namespace apache
{
  namespace activemq
  {
    namespace client
    {
      namespace marshal
      {
        using namespace ifr ;
        using namespace apache::activemq::client::command;
        using namespace apache::activemq::client::io;

/*
 *
 */
class MessageIdMarshaller : public BaseDataStreamMarshaller
{
public:
    MessageIdMarshaller() ;
    virtual ~MessageIdMarshaller() ;

    virtual DataStructure* createCommand() ;
    virtual byte getDataStructureType() ;
    
    virtual void unmarshal(OpenWireFormat& wireFormat, Object o, BinaryReader& dataIn, BooleanStream& bs) ;
    virtual int marshal1(OpenWireFormat& wireFormat, Object& o, BooleanStream& bs) ;
    virtual void marshal2(OpenWireFormat& wireFormat, Object& o, BinaryWriter& dataOut, BooleanStream& bs) ;
} ;

/* namespace */
     }
    }
  }
}
#endif /*Messag
 eIdMarshaller_hpp_*/
\ No newline at end of file

Modified: incubator/activemq/trunk/openwire-cpp/src/marshal/MessageMarshaller.cpp
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/openwire-cpp/src/marshal/MessageMarshaller.cpp?rev=383749&r1=383748&r2=383749&view=diff
==============================================================================
--- incubator/activemq/trunk/openwire-cpp/src/marshal/MessageMarshaller.cpp (original)
+++ incubator/activemq/trunk/openwire-cpp/src/marshal/MessageMarshaller.cpp Mon Mar  6 18:32:50 2006
@@ -45,33 +45,33 @@
     base.unmarshal(wireFormat, o, dataIn, bs);
 
     Message& info = (Message&) o;
-        info.setProducerId((ProducerId) tightUnmarsalCachedObject(wireFormat, dataIn, bs));
-        info.setDestination((ActiveMQDestination) tightUnmarsalCachedObject(wireFormat, dataIn, bs));
-        info.setTransactionId((TransactionId) tightUnmarsalCachedObject(wireFormat, dataIn, bs));
-        info.setOriginalDestination((ActiveMQDestination) tightUnmarsalCachedObject(wireFormat, dataIn, bs));
-        info.setMessageId((MessageId) tightUnmarsalNestedObject(wireFormat, dataIn, bs));
-        info.setOriginalTransactionId((TransactionId) tightUnmarsalCachedObject(wireFormat, dataIn, bs));
+        info.setProducerId((org.apache.activemq.command.ProducerId) tightUnmarsalCachedObject(wireFormat, dataIn, bs));
+        info.setDestination((org.apache.activemq.command.ActiveMQDestination) tightUnmarsalCachedObject(wireFormat, dataIn, bs));
+        info.setTransactionId((org.apache.activemq.command.TransactionId) tightUnmarsalCachedObject(wireFormat, dataIn, bs));
+        info.setOriginalDestination((org.apache.activemq.command.ActiveMQDestination) tightUnmarsalCachedObject(wireFormat, dataIn, bs));
+        info.setMessageId((org.apache.activemq.command.MessageId) tightUnmarsalNestedObject(wireFormat, dataIn, bs));
+        info.setOriginalTransactionId((org.apache.activemq.command.TransactionId) tightUnmarsalCachedObject(wireFormat, dataIn, bs));
         info.setGroupID(tightUnmarshalString(dataIn, bs));
         info.setGroupSequence(dataIn.readInt());
         info.setCorrelationId(tightUnmarshalString(dataIn, bs));
         info.setPersistent(bs.readBoolean());
         info.setExpiration(tightUnmarshalLong(wireFormat, dataIn, bs));
         info.setPriority(dataIn.readByte());
-        info.setReplyTo((ActiveMQDestination) tightUnmarsalNestedObject(wireFormat, dataIn, bs));
+        info.setReplyTo((org.apache.activemq.command.ActiveMQDestination) tightUnmarsalNestedObject(wireFormat, dataIn, bs));
         info.setTimestamp(tightUnmarshalLong(wireFormat, dataIn, bs));
         info.setType(tightUnmarshalString(dataIn, bs));
         info.setContent(tightUnmarshalByteSequence(dataIn, bs));
         info.setMarshalledProperties(tightUnmarshalByteSequence(dataIn, bs));
-        info.setDataStructure((DataStructure) tightUnmarsalNestedObject(wireFormat, dataIn, bs));
-        info.setTargetConsumerId((ConsumerId) tightUnmarsalCachedObject(wireFormat, dataIn, bs));
+        info.setDataStructure((org.apache.activemq.command.DataStructure) tightUnmarsalNestedObject(wireFormat, dataIn, bs));
+        info.setTargetConsumerId((org.apache.activemq.command.ConsumerId) tightUnmarsalCachedObject(wireFormat, dataIn, bs));
         info.setCompressed(bs.readBoolean());
         info.setRedeliveryCounter(dataIn.readInt());
 
         if (bs.readBoolean()) {
             short size = dataIn.readShort();
-            BrokerId value[] = new BrokerId[size];
+            org.apache.activemq.command.BrokerId value[] = new org.apache.activemq.command.BrokerId[size];
             for( int i=0; i < size; i++ ) {
-                value[i] = (BrokerId) tightUnmarsalNestedObject(wireFormat,dataIn, bs);
+                value[i] = (org.apache.activemq.command.BrokerId) tightUnmarsalNestedObject(wireFormat,dataIn, bs);
             }
             info.setBrokerPath(value);
         }

Modified: incubator/activemq/trunk/openwire-cpp/src/marshal/MessageMarshaller.hpp
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/openwire-cpp/src/marshal/MessageMarshaller.hpp?rev=383749&r1=383748&r2=383749&view=diff
==============================================================================
--- incubator/activemq/trunk/openwire-cpp/src/marshal/MessageMarshaller.hpp (original)
+++ incubator/activemq/trunk/openwire-cpp/src/marshal/MessageMarshaller.hpp Mon Mar  6 18:32:50 2006
@@ -1,71 +1 @@
-/*
-* Copyright 2006 The Apache Software Foundation or its licensors, as
-* applicable.
-*
-* Licensed under the Apache License, Version 2.0 (the "License");
-* you may not use this file except in compliance with the License.
-* You may obtain a copy of the License at
-*
-*     http://www.apache.org/licenses/LICENSE-2.0
-*
-* Unless required by applicable law or agreed to in writing, software
-* distributed under the License is distributed on an "AS IS" BASIS,
-* WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-* See the License for the specific language governing permissions and
-* limitations under the License.
-*/
-#ifndef MessageMarshaller_hpp_
-#define MessageMarshaller_hpp_
-
-#include <string>
-
-#include "command/DataStructure.hpp"
-
-/* we could cut this down  - for now include all possible headers */
-#include "command/BrokerId.hpp"
-#include "command/ConnectionId.hpp"
-#include "command/ConsumerId.hpp"
-#include "command/ProducerId.hpp"
-#include "command/SessionId.hpp"
-
-#include "io/BinaryReader.hpp"
-#include "io/BinaryWriter.hpp"
-
-#include "command/BaseCommandMarshaller.hpp"
-#include "util/ifr/p.hpp"
-
-namespace apache
-{
-  namespace activemq
-  {
-    namespace client
-    {
-      namespace marshal
-      {
-        using namespace ifr ;
-        using namespace apache::activemq::client::command;
-        using namespace apache::activemq::client::io;
-
-/*
- *
- */
-class MessageMarshaller : public BaseCommandMarshaller
-{
-public:
-    MessageMarshaller() ;
-    virtual ~MessageMarshaller() ;
-
-    virtual DataStructure* createCommand() ;
-    virtual byte getDataStructureType() ;
-    
-    virtual void unmarshal(OpenWireFormat& wireFormat, Object o, BinaryReader& dataIn, BooleanStream& bs) ;
-    virtual int marshal1(OpenWireFormat& wireFormat, Object& o, BooleanStream& bs) ;
-    virtual void marshal2(OpenWireFormat& wireFormat, Object& o, BinaryWriter& dataOut, BooleanStream& bs) ;
-} ;
-
-/* namespace */
-     }
-    }
-  }
-}
-#endif /*MessageMarshaller_hpp_*/
+/*
* Copyright 2006 The Apache Software Foundation or its licensors, as
* applicable.
*
* Licensed under the Apache License, Version 2.0 (the "License");
* you may not use this file except in compliance with the License.
* You may obtain a copy of the License at
*
*     http://www.apache.org/licenses/LICENSE-2.0
*
* Unless required by applicable law or agreed to in writing, software
* distributed under the License is distributed on an "AS IS" BASIS,
* WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
* See the License for the specific language governing permissions and
* limitations under the License.
*/
#ifndef MessageMarshaller_hpp_
#define MessageMarshaller_hpp_

#include <string>

#include "command/DataStructure.hpp"

/* we could cut this down  - for now include all possible headers */
#include "command/BrokerId.hpp"
#include "command/ConnectionId.hpp"
#include "command/ConsumerId.hpp"
#include "command/ProducerId.hpp"
#include "command/SessionId.h
 pp"

#include "io/BinaryReader.hpp"
#include "io/BinaryWriter.hpp"

#include "command/BaseCommandMarshaller.hpp"
#include "util/ifr/p.hpp"

namespace apache
{
  namespace activemq
  {
    namespace client
    {
      namespace marshal
      {
        using namespace ifr ;
        using namespace apache::activemq::client::command;
        using namespace apache::activemq::client::io;

/*
 *
 */
class MessageMarshaller : public BaseCommandMarshaller
{
public:
    MessageMarshaller() ;
    virtual ~MessageMarshaller() ;

    virtual DataStructure* createCommand() ;
    virtual byte getDataStructureType() ;
    
    virtual void unmarshal(OpenWireFormat& wireFormat, Object o, BinaryReader& dataIn, BooleanStream& bs) ;
    virtual int marshal1(OpenWireFormat& wireFormat, Object& o, BooleanStream& bs) ;
    virtual void marshal2(OpenWireFormat& wireFormat, Object& o, BinaryWriter& dataOut, BooleanStream& bs) ;
} ;

/* namespace */
     }
    }
  }
}
#endif /*MessageMarshaller_hpp_
 */
\ No newline at end of file

Added: incubator/activemq/trunk/openwire-cpp/src/marshal/NetworkBridgeFilterMarshaller.cpp
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/openwire-cpp/src/marshal/NetworkBridgeFilterMarshaller.cpp?rev=383749&view=auto
==============================================================================
--- incubator/activemq/trunk/openwire-cpp/src/marshal/NetworkBridgeFilterMarshaller.cpp (added)
+++ incubator/activemq/trunk/openwire-cpp/src/marshal/NetworkBridgeFilterMarshaller.cpp Mon Mar  6 18:32:50 2006
@@ -0,0 +1 @@
+/*
 * Copyright 2006 The Apache Software Foundation or its licensors, as
 * applicable.
 *
 * Licensed under the Apache License, Version 2.0 (the "License");
 * you may not use this file except in compliance with the License.
 * You may obtain a copy of the License at
 *
 *     http://www.apache.org/licenses/LICENSE-2.0
 *
 * Unless required by applicable law or agreed to in writing, software
 * distributed under the License is distributed on an "AS IS" BASIS,
 * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
#include "marshal/NetworkBridgeFilterMarshaller.hpp"

using namespace apache::activemq::client::marshal;

/*
 *  Marshalling code for Open Wire Format for NetworkBridgeFilter
 *
 * 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
 
 */

NetworkBridgeFilterMarshaller::NetworkBridgeFilterMarshaller()
{
    // no-op
}

NetworkBridgeFilterMarshaller::~NetworkBridgeFilterMarshaller()
{
    // no-op
}



DataStructure* NetworkBridgeFilterMarshaller::createObject() 
{
    return new NetworkBridgeFilter();
}

byte NetworkBridgeFilterMarshaller::getDataStructureType() 
{
    return NetworkBridgeFilter.ID_NetworkBridgeFilter;
}

    /* 
     * Un-marshal an object instance from the data input stream
     */ 
void NetworkBridgeFilterMarshaller::unmarshal(OpenWireFormat& wireFormat, Object o, BinaryReader& dataIn, BooleanStream& bs) 
{
    base.unmarshal(wireFormat, o, dataIn, bs);

    NetworkBridgeFilter& info = (NetworkBridgeFilter&) o;
        info.setNetworkTTL(dataIn.readInt());
        info.setNetworkBrokerId((org.apache.activemq.command.BrokerId) tightUnmarsalCachedObject(wireFormat, dataIn, bs));

}


/*
 * Write the booleans that this object uses to a BooleanStream
 */
int NetworkBridgeFilterMarshaller:
 :marshal1(OpenWireFormat& wireFormat, Object& o, BooleanStream& bs) {
    NetworkBridgeFilter& info = (NetworkBridgeFilter&) o;

    int rc = base.marshal1(wireFormat, info, bs);
        rc += marshal1CachedObject(wireFormat, info.getNetworkBrokerId(), bs);

    return rc + 1;
}

/* 
 * Write a object instance to data output stream
 */
void NetworkBridgeFilterMarshaller::marshal2(OpenWireFormat& wireFormat, Object& o, BinaryWriter& dataOut, BooleanStream& bs) {
    base.marshal2(wireFormat, o, dataOut, bs);

    NetworkBridgeFilter& info = (NetworkBridgeFilter&) o;
    DataStreamMarshaller.writeInt(info.getNetworkTTL(), dataOut);
    marshal2CachedObject(wireFormat, info.getNetworkBrokerId(), dataOut, bs);

}
\ No newline at end of file

Added: incubator/activemq/trunk/openwire-cpp/src/marshal/NetworkBridgeFilterMarshaller.hpp
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/openwire-cpp/src/marshal/NetworkBridgeFilterMarshaller.hpp?rev=383749&view=auto
==============================================================================
--- incubator/activemq/trunk/openwire-cpp/src/marshal/NetworkBridgeFilterMarshaller.hpp (added)
+++ incubator/activemq/trunk/openwire-cpp/src/marshal/NetworkBridgeFilterMarshaller.hpp Mon Mar  6 18:32:50 2006
@@ -0,0 +1 @@
+/*
* Copyright 2006 The Apache Software Foundation or its licensors, as
* applicable.
*
* Licensed under the Apache License, Version 2.0 (the "License");
* you may not use this file except in compliance with the License.
* You may obtain a copy of the License at
*
*     http://www.apache.org/licenses/LICENSE-2.0
*
* Unless required by applicable law or agreed to in writing, software
* distributed under the License is distributed on an "AS IS" BASIS,
* WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
* See the License for the specific language governing permissions and
* limitations under the License.
*/
#ifndef NetworkBridgeFilterMarshaller_hpp_
#define NetworkBridgeFilterMarshaller_hpp_

#include <string>

#include "command/DataStructure.hpp"

/* we could cut this down  - for now include all possible headers */
#include "command/BrokerId.hpp"
#include "command/ConnectionId.hpp"
#include "command/ConsumerId.hpp"
#include "command/ProducerId.hpp"
#incl
 ude "command/SessionId.hpp"

#include "io/BinaryReader.hpp"
#include "io/BinaryWriter.hpp"

#include "command/BaseDataStreamMarshaller.hpp"
#include "util/ifr/p.hpp"

namespace apache
{
  namespace activemq
  {
    namespace client
    {
      namespace marshal
      {
        using namespace ifr ;
        using namespace apache::activemq::client::command;
        using namespace apache::activemq::client::io;

/*
 *
 */
class NetworkBridgeFilterMarshaller : public BaseDataStreamMarshaller
{
public:
    NetworkBridgeFilterMarshaller() ;
    virtual ~NetworkBridgeFilterMarshaller() ;

    virtual DataStructure* createCommand() ;
    virtual byte getDataStructureType() ;
    
    virtual void unmarshal(OpenWireFormat& wireFormat, Object o, BinaryReader& dataIn, BooleanStream& bs) ;
    virtual int marshal1(OpenWireFormat& wireFormat, Object& o, BooleanStream& bs) ;
    virtual void marshal2(OpenWireFormat& wireFormat, Object& o, BinaryWriter& dataOut, BooleanStream& bs) ;
} ;

 /* namespace */
     }
    }
  }
}
#endif /*NetworkBridgeFilterMarshaller_hpp_*/
\ No newline at end of file

Modified: incubator/activemq/trunk/openwire-cpp/src/marshal/ProducerIdMarshaller.hpp
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/openwire-cpp/src/marshal/ProducerIdMarshaller.hpp?rev=383749&r1=383748&r2=383749&view=diff
==============================================================================
--- incubator/activemq/trunk/openwire-cpp/src/marshal/ProducerIdMarshaller.hpp (original)
+++ incubator/activemq/trunk/openwire-cpp/src/marshal/ProducerIdMarshaller.hpp Mon Mar  6 18:32:50 2006
@@ -1,71 +1 @@
-/*
-* Copyright 2006 The Apache Software Foundation or its licensors, as
-* applicable.
-*
-* Licensed under the Apache License, Version 2.0 (the "License");
-* you may not use this file except in compliance with the License.
-* You may obtain a copy of the License at
-*
-*     http://www.apache.org/licenses/LICENSE-2.0
-*
-* Unless required by applicable law or agreed to in writing, software
-* distributed under the License is distributed on an "AS IS" BASIS,
-* WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-* See the License for the specific language governing permissions and
-* limitations under the License.
-*/
-#ifndef ProducerIdMarshaller_hpp_
-#define ProducerIdMarshaller_hpp_
-
-#include <string>
-
-#include "command/DataStructure.hpp"
-
-/* we could cut this down  - for now include all possible headers */
-#include "command/BrokerId.hpp"
-#include "command/ConnectionId.hpp"
-#include "command/ConsumerId.hpp"
-#include "command/ProducerId.hpp"
-#include "command/SessionId.hpp"
-
-#include "io/BinaryReader.hpp"
-#include "io/BinaryWriter.hpp"
-
-#include "command/BaseDataStreamMarshaller.hpp"
-#include "util/ifr/p.hpp"
-
-namespace apache
-{
-  namespace activemq
-  {
-    namespace client
-    {
-      namespace marshal
-      {
-        using namespace ifr ;
-        using namespace apache::activemq::client::command;
-        using namespace apache::activemq::client::io;
-
-/*
- *
- */
-class ProducerIdMarshaller : public BaseDataStreamMarshaller
-{
-public:
-    ProducerIdMarshaller() ;
-    virtual ~ProducerIdMarshaller() ;
-
-    virtual DataStructure* createCommand() ;
-    virtual byte getDataStructureType() ;
-    
-    virtual void unmarshal(OpenWireFormat& wireFormat, Object o, BinaryReader& dataIn, BooleanStream& bs) ;
-    virtual int marshal1(OpenWireFormat& wireFormat, Object& o, BooleanStream& bs) ;
-    virtual void marshal2(OpenWireFormat& wireFormat, Object& o, BinaryWriter& dataOut, BooleanStream& bs) ;
-} ;
-
-/* namespace */
-     }
-    }
-  }
-}
-#endif /*ProducerIdMarshaller_hpp_*/
+/*
* Copyright 2006 The Apache Software Foundation or its licensors, as
* applicable.
*
* Licensed under the Apache License, Version 2.0 (the "License");
* you may not use this file except in compliance with the License.
* You may obtain a copy of the License at
*
*     http://www.apache.org/licenses/LICENSE-2.0
*
* Unless required by applicable law or agreed to in writing, software
* distributed under the License is distributed on an "AS IS" BASIS,
* WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
* See the License for the specific language governing permissions and
* limitations under the License.
*/
#ifndef ProducerIdMarshaller_hpp_
#define ProducerIdMarshaller_hpp_

#include <string>

#include "command/DataStructure.hpp"

/* we could cut this down  - for now include all possible headers */
#include "command/BrokerId.hpp"
#include "command/ConnectionId.hpp"
#include "command/ConsumerId.hpp"
#include "command/ProducerId.hpp"
#include "command/Sessi
 onId.hpp"

#include "io/BinaryReader.hpp"
#include "io/BinaryWriter.hpp"

#include "command/BaseDataStreamMarshaller.hpp"
#include "util/ifr/p.hpp"

namespace apache
{
  namespace activemq
  {
    namespace client
    {
      namespace marshal
      {
        using namespace ifr ;
        using namespace apache::activemq::client::command;
        using namespace apache::activemq::client::io;

/*
 *
 */
class ProducerIdMarshaller : public BaseDataStreamMarshaller
{
public:
    ProducerIdMarshaller() ;
    virtual ~ProducerIdMarshaller() ;

    virtual DataStructure* createCommand() ;
    virtual byte getDataStructureType() ;
    
    virtual void unmarshal(OpenWireFormat& wireFormat, Object o, BinaryReader& dataIn, BooleanStream& bs) ;
    virtual int marshal1(OpenWireFormat& wireFormat, Object& o, BooleanStream& bs) ;
    virtual void marshal2(OpenWireFormat& wireFormat, Object& o, BinaryWriter& dataOut, BooleanStream& bs) ;
} ;

/* namespace */
     }
    }
  }
}
#endif /*P
 roducerIdMarshaller_hpp_*/
\ No newline at end of file

Modified: incubator/activemq/trunk/openwire-cpp/src/marshal/ProducerInfoMarshaller.cpp
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/openwire-cpp/src/marshal/ProducerInfoMarshaller.cpp?rev=383749&r1=383748&r2=383749&view=diff
==============================================================================
--- incubator/activemq/trunk/openwire-cpp/src/marshal/ProducerInfoMarshaller.cpp (original)
+++ incubator/activemq/trunk/openwire-cpp/src/marshal/ProducerInfoMarshaller.cpp Mon Mar  6 18:32:50 2006
@@ -56,14 +56,14 @@
     base.unmarshal(wireFormat, o, dataIn, bs);
 
     ProducerInfo& info = (ProducerInfo&) o;
-        info.setProducerId((ProducerId) tightUnmarsalCachedObject(wireFormat, dataIn, bs));
-        info.setDestination((ActiveMQDestination) tightUnmarsalCachedObject(wireFormat, dataIn, bs));
+        info.setProducerId((org.apache.activemq.command.ProducerId) tightUnmarsalCachedObject(wireFormat, dataIn, bs));
+        info.setDestination((org.apache.activemq.command.ActiveMQDestination) tightUnmarsalCachedObject(wireFormat, dataIn, bs));
 
         if (bs.readBoolean()) {
             short size = dataIn.readShort();
-            BrokerId value[] = new BrokerId[size];
+            org.apache.activemq.command.BrokerId value[] = new org.apache.activemq.command.BrokerId[size];
             for( int i=0; i < size; i++ ) {
-                value[i] = (BrokerId) tightUnmarsalNestedObject(wireFormat,dataIn, bs);
+                value[i] = (org.apache.activemq.command.BrokerId) tightUnmarsalNestedObject(wireFormat,dataIn, bs);
             }
             info.setBrokerPath(value);
         }

Modified: incubator/activemq/trunk/openwire-cpp/src/marshal/ProducerInfoMarshaller.hpp
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/openwire-cpp/src/marshal/ProducerInfoMarshaller.hpp?rev=383749&r1=383748&r2=383749&view=diff
==============================================================================
--- incubator/activemq/trunk/openwire-cpp/src/marshal/ProducerInfoMarshaller.hpp (original)
+++ incubator/activemq/trunk/openwire-cpp/src/marshal/ProducerInfoMarshaller.hpp Mon Mar  6 18:32:50 2006
@@ -1,71 +1 @@
-/*
-* Copyright 2006 The Apache Software Foundation or its licensors, as
-* applicable.
-*
-* Licensed under the Apache License, Version 2.0 (the "License");
-* you may not use this file except in compliance with the License.
-* You may obtain a copy of the License at
-*
-*     http://www.apache.org/licenses/LICENSE-2.0
-*
-* Unless required by applicable law or agreed to in writing, software
-* distributed under the License is distributed on an "AS IS" BASIS,
-* WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-* See the License for the specific language governing permissions and
-* limitations under the License.
-*/
-#ifndef ProducerInfoMarshaller_hpp_
-#define ProducerInfoMarshaller_hpp_
-
-#include <string>
-
-#include "command/DataStructure.hpp"
-
-/* we could cut this down  - for now include all possible headers */
-#include "command/BrokerId.hpp"
-#include "command/ConnectionId.hpp"
-#include "command/ConsumerId.hpp"
-#include "command/ProducerId.hpp"
-#include "command/SessionId.hpp"
-
-#include "io/BinaryReader.hpp"
-#include "io/BinaryWriter.hpp"
-
-#include "command/BaseCommandMarshaller.hpp"
-#include "util/ifr/p.hpp"
-
-namespace apache
-{
-  namespace activemq
-  {
-    namespace client
-    {
-      namespace marshal
-      {
-        using namespace ifr ;
-        using namespace apache::activemq::client::command;
-        using namespace apache::activemq::client::io;
-
-/*
- *
- */
-class ProducerInfoMarshaller : public BaseCommandMarshaller
-{
-public:
-    ProducerInfoMarshaller() ;
-    virtual ~ProducerInfoMarshaller() ;
-
-    virtual DataStructure* createCommand() ;
-    virtual byte getDataStructureType() ;
-    
-    virtual void unmarshal(OpenWireFormat& wireFormat, Object o, BinaryReader& dataIn, BooleanStream& bs) ;
-    virtual int marshal1(OpenWireFormat& wireFormat, Object& o, BooleanStream& bs) ;
-    virtual void marshal2(OpenWireFormat& wireFormat, Object& o, BinaryWriter& dataOut, BooleanStream& bs) ;
-} ;
-
-/* namespace */
-     }
-    }
-  }
-}
-#endif /*ProducerInfoMarshaller_hpp_*/
+/*
* Copyright 2006 The Apache Software Foundation or its licensors, as
* applicable.
*
* Licensed under the Apache License, Version 2.0 (the "License");
* you may not use this file except in compliance with the License.
* You may obtain a copy of the License at
*
*     http://www.apache.org/licenses/LICENSE-2.0
*
* Unless required by applicable law or agreed to in writing, software
* distributed under the License is distributed on an "AS IS" BASIS,
* WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
* See the License for the specific language governing permissions and
* limitations under the License.
*/
#ifndef ProducerInfoMarshaller_hpp_
#define ProducerInfoMarshaller_hpp_

#include <string>

#include "command/DataStructure.hpp"

/* we could cut this down  - for now include all possible headers */
#include "command/BrokerId.hpp"
#include "command/ConnectionId.hpp"
#include "command/ConsumerId.hpp"
#include "command/ProducerId.hpp"
#include "command/S
 essionId.hpp"

#include "io/BinaryReader.hpp"
#include "io/BinaryWriter.hpp"

#include "command/BaseCommandMarshaller.hpp"
#include "util/ifr/p.hpp"

namespace apache
{
  namespace activemq
  {
    namespace client
    {
      namespace marshal
      {
        using namespace ifr ;
        using namespace apache::activemq::client::command;
        using namespace apache::activemq::client::io;

/*
 *
 */
class ProducerInfoMarshaller : public BaseCommandMarshaller
{
public:
    ProducerInfoMarshaller() ;
    virtual ~ProducerInfoMarshaller() ;

    virtual DataStructure* createCommand() ;
    virtual byte getDataStructureType() ;
    
    virtual void unmarshal(OpenWireFormat& wireFormat, Object o, BinaryReader& dataIn, BooleanStream& bs) ;
    virtual int marshal1(OpenWireFormat& wireFormat, Object& o, BooleanStream& bs) ;
    virtual void marshal2(OpenWireFormat& wireFormat, Object& o, BinaryWriter& dataOut, BooleanStream& bs) ;
} ;

/* namespace */
     }
    }
  }
}
#endif
  /*ProducerInfoMarshaller_hpp_*/
\ No newline at end of file

Modified: incubator/activemq/trunk/openwire-cpp/src/marshal/RemoveInfoMarshaller.cpp
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/openwire-cpp/src/marshal/RemoveInfoMarshaller.cpp?rev=383749&r1=383748&r2=383749&view=diff
==============================================================================
--- incubator/activemq/trunk/openwire-cpp/src/marshal/RemoveInfoMarshaller.cpp (original)
+++ incubator/activemq/trunk/openwire-cpp/src/marshal/RemoveInfoMarshaller.cpp Mon Mar  6 18:32:50 2006
@@ -56,7 +56,7 @@
     base.unmarshal(wireFormat, o, dataIn, bs);
 
     RemoveInfo& info = (RemoveInfo&) o;
-        info.setObjectId((DataStructure) tightUnmarsalCachedObject(wireFormat, dataIn, bs));
+        info.setObjectId((org.apache.activemq.command.DataStructure) tightUnmarsalCachedObject(wireFormat, dataIn, bs));
 
 }
 

Modified: incubator/activemq/trunk/openwire-cpp/src/marshal/RemoveInfoMarshaller.hpp
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/openwire-cpp/src/marshal/RemoveInfoMarshaller.hpp?rev=383749&r1=383748&r2=383749&view=diff
==============================================================================
--- incubator/activemq/trunk/openwire-cpp/src/marshal/RemoveInfoMarshaller.hpp (original)
+++ incubator/activemq/trunk/openwire-cpp/src/marshal/RemoveInfoMarshaller.hpp Mon Mar  6 18:32:50 2006
@@ -1,71 +1 @@
-/*
-* Copyright 2006 The Apache Software Foundation or its licensors, as
-* applicable.
-*
-* Licensed under the Apache License, Version 2.0 (the "License");
-* you may not use this file except in compliance with the License.
-* You may obtain a copy of the License at
-*
-*     http://www.apache.org/licenses/LICENSE-2.0
-*
-* Unless required by applicable law or agreed to in writing, software
-* distributed under the License is distributed on an "AS IS" BASIS,
-* WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-* See the License for the specific language governing permissions and
-* limitations under the License.
-*/
-#ifndef RemoveInfoMarshaller_hpp_
-#define RemoveInfoMarshaller_hpp_
-
-#include <string>
-
-#include "command/DataStructure.hpp"
-
-/* we could cut this down  - for now include all possible headers */
-#include "command/BrokerId.hpp"
-#include "command/ConnectionId.hpp"
-#include "command/ConsumerId.hpp"
-#include "command/ProducerId.hpp"
-#include "command/SessionId.hpp"
-
-#include "io/BinaryReader.hpp"
-#include "io/BinaryWriter.hpp"
-
-#include "command/BaseCommandMarshaller.hpp"
-#include "util/ifr/p.hpp"
-
-namespace apache
-{
-  namespace activemq
-  {
-    namespace client
-    {
-      namespace marshal
-      {
-        using namespace ifr ;
-        using namespace apache::activemq::client::command;
-        using namespace apache::activemq::client::io;
-
-/*
- *
- */
-class RemoveInfoMarshaller : public BaseCommandMarshaller
-{
-public:
-    RemoveInfoMarshaller() ;
-    virtual ~RemoveInfoMarshaller() ;
-
-    virtual DataStructure* createCommand() ;
-    virtual byte getDataStructureType() ;
-    
-    virtual void unmarshal(OpenWireFormat& wireFormat, Object o, BinaryReader& dataIn, BooleanStream& bs) ;
-    virtual int marshal1(OpenWireFormat& wireFormat, Object& o, BooleanStream& bs) ;
-    virtual void marshal2(OpenWireFormat& wireFormat, Object& o, BinaryWriter& dataOut, BooleanStream& bs) ;
-} ;
-
-/* namespace */
-     }
-    }
-  }
-}
-#endif /*RemoveInfoMarshaller_hpp_*/
+/*
* Copyright 2006 The Apache Software Foundation or its licensors, as
* applicable.
*
* Licensed under the Apache License, Version 2.0 (the "License");
* you may not use this file except in compliance with the License.
* You may obtain a copy of the License at
*
*     http://www.apache.org/licenses/LICENSE-2.0
*
* Unless required by applicable law or agreed to in writing, software
* distributed under the License is distributed on an "AS IS" BASIS,
* WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
* See the License for the specific language governing permissions and
* limitations under the License.
*/
#ifndef RemoveInfoMarshaller_hpp_
#define RemoveInfoMarshaller_hpp_

#include <string>

#include "command/DataStructure.hpp"

/* we could cut this down  - for now include all possible headers */
#include "command/BrokerId.hpp"
#include "command/ConnectionId.hpp"
#include "command/ConsumerId.hpp"
#include "command/ProducerId.hpp"
#include "command/Sessi
 onId.hpp"

#include "io/BinaryReader.hpp"
#include "io/BinaryWriter.hpp"

#include "command/BaseCommandMarshaller.hpp"
#include "util/ifr/p.hpp"

namespace apache
{
  namespace activemq
  {
    namespace client
    {
      namespace marshal
      {
        using namespace ifr ;
        using namespace apache::activemq::client::command;
        using namespace apache::activemq::client::io;

/*
 *
 */
class RemoveInfoMarshaller : public BaseCommandMarshaller
{
public:
    RemoveInfoMarshaller() ;
    virtual ~RemoveInfoMarshaller() ;

    virtual DataStructure* createCommand() ;
    virtual byte getDataStructureType() ;
    
    virtual void unmarshal(OpenWireFormat& wireFormat, Object o, BinaryReader& dataIn, BooleanStream& bs) ;
    virtual int marshal1(OpenWireFormat& wireFormat, Object& o, BooleanStream& bs) ;
    virtual void marshal2(OpenWireFormat& wireFormat, Object& o, BinaryWriter& dataOut, BooleanStream& bs) ;
} ;

/* namespace */
     }
    }
  }
}
#endif /*RemoveI
 nfoMarshaller_hpp_*/
\ No newline at end of file

Modified: incubator/activemq/trunk/openwire-cpp/src/marshal/RemoveSubscriptionInfoMarshaller.cpp
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/openwire-cpp/src/marshal/RemoveSubscriptionInfoMarshaller.cpp?rev=383749&r1=383748&r2=383749&view=diff
==============================================================================
--- incubator/activemq/trunk/openwire-cpp/src/marshal/RemoveSubscriptionInfoMarshaller.cpp (original)
+++ incubator/activemq/trunk/openwire-cpp/src/marshal/RemoveSubscriptionInfoMarshaller.cpp Mon Mar  6 18:32:50 2006
@@ -56,7 +56,7 @@
     base.unmarshal(wireFormat, o, dataIn, bs);
 
     RemoveSubscriptionInfo& info = (RemoveSubscriptionInfo&) o;
-        info.setConnectionId((ConnectionId) tightUnmarsalCachedObject(wireFormat, dataIn, bs));
+        info.setConnectionId((org.apache.activemq.command.ConnectionId) tightUnmarsalCachedObject(wireFormat, dataIn, bs));
         info.setSubcriptionName(tightUnmarshalString(dataIn, bs));
         info.setClientId(tightUnmarshalString(dataIn, bs));
 

Modified: incubator/activemq/trunk/openwire-cpp/src/marshal/RemoveSubscriptionInfoMarshaller.hpp
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/openwire-cpp/src/marshal/RemoveSubscriptionInfoMarshaller.hpp?rev=383749&r1=383748&r2=383749&view=diff
==============================================================================
--- incubator/activemq/trunk/openwire-cpp/src/marshal/RemoveSubscriptionInfoMarshaller.hpp (original)
+++ incubator/activemq/trunk/openwire-cpp/src/marshal/RemoveSubscriptionInfoMarshaller.hpp Mon Mar  6 18:32:50 2006
@@ -1,71 +1 @@
-/*
-* Copyright 2006 The Apache Software Foundation or its licensors, as
-* applicable.
-*
-* Licensed under the Apache License, Version 2.0 (the "License");
-* you may not use this file except in compliance with the License.
-* You may obtain a copy of the License at
-*
-*     http://www.apache.org/licenses/LICENSE-2.0
-*
-* Unless required by applicable law or agreed to in writing, software
-* distributed under the License is distributed on an "AS IS" BASIS,
-* WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-* See the License for the specific language governing permissions and
-* limitations under the License.
-*/
-#ifndef RemoveSubscriptionInfoMarshaller_hpp_
-#define RemoveSubscriptionInfoMarshaller_hpp_
-
-#include <string>
-
-#include "command/DataStructure.hpp"
-
-/* we could cut this down  - for now include all possible headers */
-#include "command/BrokerId.hpp"
-#include "command/ConnectionId.hpp"
-#include "command/ConsumerId.hpp"
-#include "command/ProducerId.hpp"
-#include "command/SessionId.hpp"
-
-#include "io/BinaryReader.hpp"
-#include "io/BinaryWriter.hpp"
-
-#include "command/BaseCommandMarshaller.hpp"
-#include "util/ifr/p.hpp"
-
-namespace apache
-{
-  namespace activemq
-  {
-    namespace client
-    {
-      namespace marshal
-      {
-        using namespace ifr ;
-        using namespace apache::activemq::client::command;
-        using namespace apache::activemq::client::io;
-
-/*
- *
- */
-class RemoveSubscriptionInfoMarshaller : public BaseCommandMarshaller
-{
-public:
-    RemoveSubscriptionInfoMarshaller() ;
-    virtual ~RemoveSubscriptionInfoMarshaller() ;
-
-    virtual DataStructure* createCommand() ;
-    virtual byte getDataStructureType() ;
-    
-    virtual void unmarshal(OpenWireFormat& wireFormat, Object o, BinaryReader& dataIn, BooleanStream& bs) ;
-    virtual int marshal1(OpenWireFormat& wireFormat, Object& o, BooleanStream& bs) ;
-    virtual void marshal2(OpenWireFormat& wireFormat, Object& o, BinaryWriter& dataOut, BooleanStream& bs) ;
-} ;
-
-/* namespace */
-     }
-    }
-  }
-}
-#endif /*RemoveSubscriptionInfoMarshaller_hpp_*/
+/*
* Copyright 2006 The Apache Software Foundation or its licensors, as
* applicable.
*
* Licensed under the Apache License, Version 2.0 (the "License");
* you may not use this file except in compliance with the License.
* You may obtain a copy of the License at
*
*     http://www.apache.org/licenses/LICENSE-2.0
*
* Unless required by applicable law or agreed to in writing, software
* distributed under the License is distributed on an "AS IS" BASIS,
* WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
* See the License for the specific language governing permissions and
* limitations under the License.
*/
#ifndef RemoveSubscriptionInfoMarshaller_hpp_
#define RemoveSubscriptionInfoMarshaller_hpp_

#include <string>

#include "command/DataStructure.hpp"

/* we could cut this down  - for now include all possible headers */
#include "command/BrokerId.hpp"
#include "command/ConnectionId.hpp"
#include "command/ConsumerId.hpp"
#include "command/ProducerId.hpp"
 
#include "command/SessionId.hpp"

#include "io/BinaryReader.hpp"
#include "io/BinaryWriter.hpp"

#include "command/BaseCommandMarshaller.hpp"
#include "util/ifr/p.hpp"

namespace apache
{
  namespace activemq
  {
    namespace client
    {
      namespace marshal
      {
        using namespace ifr ;
        using namespace apache::activemq::client::command;
        using namespace apache::activemq::client::io;

/*
 *
 */
class RemoveSubscriptionInfoMarshaller : public BaseCommandMarshaller
{
public:
    RemoveSubscriptionInfoMarshaller() ;
    virtual ~RemoveSubscriptionInfoMarshaller() ;

    virtual DataStructure* createCommand() ;
    virtual byte getDataStructureType() ;
    
    virtual void unmarshal(OpenWireFormat& wireFormat, Object o, BinaryReader& dataIn, BooleanStream& bs) ;
    virtual int marshal1(OpenWireFormat& wireFormat, Object& o, BooleanStream& bs) ;
    virtual void marshal2(OpenWireFormat& wireFormat, Object& o, BinaryWriter& dataOut, BooleanStream& bs
 ) ;
} ;

/* namespace */
     }
    }
  }
}
#endif /*RemoveSubscriptionInfoMarshaller_hpp_*/
\ No newline at end of file

Modified: incubator/activemq/trunk/openwire-cpp/src/marshal/ResponseMarshaller.hpp
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/openwire-cpp/src/marshal/ResponseMarshaller.hpp?rev=383749&r1=383748&r2=383749&view=diff
==============================================================================
--- incubator/activemq/trunk/openwire-cpp/src/marshal/ResponseMarshaller.hpp (original)
+++ incubator/activemq/trunk/openwire-cpp/src/marshal/ResponseMarshaller.hpp Mon Mar  6 18:32:50 2006
@@ -1,71 +1 @@
-/*
-* Copyright 2006 The Apache Software Foundation or its licensors, as
-* applicable.
-*
-* Licensed under the Apache License, Version 2.0 (the "License");
-* you may not use this file except in compliance with the License.
-* You may obtain a copy of the License at
-*
-*     http://www.apache.org/licenses/LICENSE-2.0
-*
-* Unless required by applicable law or agreed to in writing, software
-* distributed under the License is distributed on an "AS IS" BASIS,
-* WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-* See the License for the specific language governing permissions and
-* limitations under the License.
-*/
-#ifndef ResponseMarshaller_hpp_
-#define ResponseMarshaller_hpp_
-
-#include <string>
-
-#include "command/DataStructure.hpp"
-
-/* we could cut this down  - for now include all possible headers */
-#include "command/BrokerId.hpp"
-#include "command/ConnectionId.hpp"
-#include "command/ConsumerId.hpp"
-#include "command/ProducerId.hpp"
-#include "command/SessionId.hpp"
-
-#include "io/BinaryReader.hpp"
-#include "io/BinaryWriter.hpp"
-
-#include "command/BaseCommandMarshaller.hpp"
-#include "util/ifr/p.hpp"
-
-namespace apache
-{
-  namespace activemq
-  {
-    namespace client
-    {
-      namespace marshal
-      {
-        using namespace ifr ;
-        using namespace apache::activemq::client::command;
-        using namespace apache::activemq::client::io;
-
-/*
- *
- */
-class ResponseMarshaller : public BaseCommandMarshaller
-{
-public:
-    ResponseMarshaller() ;
-    virtual ~ResponseMarshaller() ;
-
-    virtual DataStructure* createCommand() ;
-    virtual byte getDataStructureType() ;
-    
-    virtual void unmarshal(OpenWireFormat& wireFormat, Object o, BinaryReader& dataIn, BooleanStream& bs) ;
-    virtual int marshal1(OpenWireFormat& wireFormat, Object& o, BooleanStream& bs) ;
-    virtual void marshal2(OpenWireFormat& wireFormat, Object& o, BinaryWriter& dataOut, BooleanStream& bs) ;
-} ;
-
-/* namespace */
-     }
-    }
-  }
-}
-#endif /*ResponseMarshaller_hpp_*/
+/*
* Copyright 2006 The Apache Software Foundation or its licensors, as
* applicable.
*
* Licensed under the Apache License, Version 2.0 (the "License");
* you may not use this file except in compliance with the License.
* You may obtain a copy of the License at
*
*     http://www.apache.org/licenses/LICENSE-2.0
*
* Unless required by applicable law or agreed to in writing, software
* distributed under the License is distributed on an "AS IS" BASIS,
* WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
* See the License for the specific language governing permissions and
* limitations under the License.
*/
#ifndef ResponseMarshaller_hpp_
#define ResponseMarshaller_hpp_

#include <string>

#include "command/DataStructure.hpp"

/* we could cut this down  - for now include all possible headers */
#include "command/BrokerId.hpp"
#include "command/ConnectionId.hpp"
#include "command/ConsumerId.hpp"
#include "command/ProducerId.hpp"
#include "command/SessionId
 .hpp"

#include "io/BinaryReader.hpp"
#include "io/BinaryWriter.hpp"

#include "command/BaseCommandMarshaller.hpp"
#include "util/ifr/p.hpp"

namespace apache
{
  namespace activemq
  {
    namespace client
    {
      namespace marshal
      {
        using namespace ifr ;
        using namespace apache::activemq::client::command;
        using namespace apache::activemq::client::io;

/*
 *
 */
class ResponseMarshaller : public BaseCommandMarshaller
{
public:
    ResponseMarshaller() ;
    virtual ~ResponseMarshaller() ;

    virtual DataStructure* createCommand() ;
    virtual byte getDataStructureType() ;
    
    virtual void unmarshal(OpenWireFormat& wireFormat, Object o, BinaryReader& dataIn, BooleanStream& bs) ;
    virtual int marshal1(OpenWireFormat& wireFormat, Object& o, BooleanStream& bs) ;
    virtual void marshal2(OpenWireFormat& wireFormat, Object& o, BinaryWriter& dataOut, BooleanStream& bs) ;
} ;

/* namespace */
     }
    }
  }
}
#endif /*ResponseMarshalle
 r_hpp_*/
\ No newline at end of file

Modified: incubator/activemq/trunk/openwire-cpp/src/marshal/SessionIdMarshaller.hpp
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/openwire-cpp/src/marshal/SessionIdMarshaller.hpp?rev=383749&r1=383748&r2=383749&view=diff
==============================================================================
--- incubator/activemq/trunk/openwire-cpp/src/marshal/SessionIdMarshaller.hpp (original)
+++ incubator/activemq/trunk/openwire-cpp/src/marshal/SessionIdMarshaller.hpp Mon Mar  6 18:32:50 2006
@@ -1,71 +1 @@
-/*
-* Copyright 2006 The Apache Software Foundation or its licensors, as
-* applicable.
-*
-* Licensed under the Apache License, Version 2.0 (the "License");
-* you may not use this file except in compliance with the License.
-* You may obtain a copy of the License at
-*
-*     http://www.apache.org/licenses/LICENSE-2.0
-*
-* Unless required by applicable law or agreed to in writing, software
-* distributed under the License is distributed on an "AS IS" BASIS,
-* WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-* See the License for the specific language governing permissions and
-* limitations under the License.
-*/
-#ifndef SessionIdMarshaller_hpp_
-#define SessionIdMarshaller_hpp_
-
-#include <string>
-
-#include "command/DataStructure.hpp"
-
-/* we could cut this down  - for now include all possible headers */
-#include "command/BrokerId.hpp"
-#include "command/ConnectionId.hpp"
-#include "command/ConsumerId.hpp"
-#include "command/ProducerId.hpp"
-#include "command/SessionId.hpp"
-
-#include "io/BinaryReader.hpp"
-#include "io/BinaryWriter.hpp"
-
-#include "command/BaseDataStreamMarshaller.hpp"
-#include "util/ifr/p.hpp"
-
-namespace apache
-{
-  namespace activemq
-  {
-    namespace client
-    {
-      namespace marshal
-      {
-        using namespace ifr ;
-        using namespace apache::activemq::client::command;
-        using namespace apache::activemq::client::io;
-
-/*
- *
- */
-class SessionIdMarshaller : public BaseDataStreamMarshaller
-{
-public:
-    SessionIdMarshaller() ;
-    virtual ~SessionIdMarshaller() ;
-
-    virtual DataStructure* createCommand() ;
-    virtual byte getDataStructureType() ;
-    
-    virtual void unmarshal(OpenWireFormat& wireFormat, Object o, BinaryReader& dataIn, BooleanStream& bs) ;
-    virtual int marshal1(OpenWireFormat& wireFormat, Object& o, BooleanStream& bs) ;
-    virtual void marshal2(OpenWireFormat& wireFormat, Object& o, BinaryWriter& dataOut, BooleanStream& bs) ;
-} ;
-
-/* namespace */
-     }
-    }
-  }
-}
-#endif /*SessionIdMarshaller_hpp_*/
+/*
* Copyright 2006 The Apache Software Foundation or its licensors, as
* applicable.
*
* Licensed under the Apache License, Version 2.0 (the "License");
* you may not use this file except in compliance with the License.
* You may obtain a copy of the License at
*
*     http://www.apache.org/licenses/LICENSE-2.0
*
* Unless required by applicable law or agreed to in writing, software
* distributed under the License is distributed on an "AS IS" BASIS,
* WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
* See the License for the specific language governing permissions and
* limitations under the License.
*/
#ifndef SessionIdMarshaller_hpp_
#define SessionIdMarshaller_hpp_

#include <string>

#include "command/DataStructure.hpp"

/* we could cut this down  - for now include all possible headers */
#include "command/BrokerId.hpp"
#include "command/ConnectionId.hpp"
#include "command/ConsumerId.hpp"
#include "command/ProducerId.hpp"
#include "command/Session
 Id.hpp"

#include "io/BinaryReader.hpp"
#include "io/BinaryWriter.hpp"

#include "command/BaseDataStreamMarshaller.hpp"
#include "util/ifr/p.hpp"

namespace apache
{
  namespace activemq
  {
    namespace client
    {
      namespace marshal
      {
        using namespace ifr ;
        using namespace apache::activemq::client::command;
        using namespace apache::activemq::client::io;

/*
 *
 */
class SessionIdMarshaller : public BaseDataStreamMarshaller
{
public:
    SessionIdMarshaller() ;
    virtual ~SessionIdMarshaller() ;

    virtual DataStructure* createCommand() ;
    virtual byte getDataStructureType() ;
    
    virtual void unmarshal(OpenWireFormat& wireFormat, Object o, BinaryReader& dataIn, BooleanStream& bs) ;
    virtual int marshal1(OpenWireFormat& wireFormat, Object& o, BooleanStream& bs) ;
    virtual void marshal2(OpenWireFormat& wireFormat, Object& o, BinaryWriter& dataOut, BooleanStream& bs) ;
} ;

/* namespace */
     }
    }
  }
}
#endif /*Sessio
 nIdMarshaller_hpp_*/
\ No newline at end of file

Modified: incubator/activemq/trunk/openwire-cpp/src/marshal/SessionInfoMarshaller.cpp
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/openwire-cpp/src/marshal/SessionInfoMarshaller.cpp?rev=383749&r1=383748&r2=383749&view=diff
==============================================================================
--- incubator/activemq/trunk/openwire-cpp/src/marshal/SessionInfoMarshaller.cpp (original)
+++ incubator/activemq/trunk/openwire-cpp/src/marshal/SessionInfoMarshaller.cpp Mon Mar  6 18:32:50 2006
@@ -56,7 +56,7 @@
     base.unmarshal(wireFormat, o, dataIn, bs);
 
     SessionInfo& info = (SessionInfo&) o;
-        info.setSessionId((SessionId) tightUnmarsalCachedObject(wireFormat, dataIn, bs));
+        info.setSessionId((org.apache.activemq.command.SessionId) tightUnmarsalCachedObject(wireFormat, dataIn, bs));
 
 }
 

Modified: incubator/activemq/trunk/openwire-cpp/src/marshal/SessionInfoMarshaller.hpp
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/openwire-cpp/src/marshal/SessionInfoMarshaller.hpp?rev=383749&r1=383748&r2=383749&view=diff
==============================================================================
--- incubator/activemq/trunk/openwire-cpp/src/marshal/SessionInfoMarshaller.hpp (original)
+++ incubator/activemq/trunk/openwire-cpp/src/marshal/SessionInfoMarshaller.hpp Mon Mar  6 18:32:50 2006
@@ -1,71 +1 @@
-/*
-* Copyright 2006 The Apache Software Foundation or its licensors, as
-* applicable.
-*
-* Licensed under the Apache License, Version 2.0 (the "License");
-* you may not use this file except in compliance with the License.
-* You may obtain a copy of the License at
-*
-*     http://www.apache.org/licenses/LICENSE-2.0
-*
-* Unless required by applicable law or agreed to in writing, software
-* distributed under the License is distributed on an "AS IS" BASIS,
-* WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-* See the License for the specific language governing permissions and
-* limitations under the License.
-*/
-#ifndef SessionInfoMarshaller_hpp_
-#define SessionInfoMarshaller_hpp_
-
-#include <string>
-
-#include "command/DataStructure.hpp"
-
-/* we could cut this down  - for now include all possible headers */
-#include "command/BrokerId.hpp"
-#include "command/ConnectionId.hpp"
-#include "command/ConsumerId.hpp"
-#include "command/ProducerId.hpp"
-#include "command/SessionId.hpp"
-
-#include "io/BinaryReader.hpp"
-#include "io/BinaryWriter.hpp"
-
-#include "command/BaseCommandMarshaller.hpp"
-#include "util/ifr/p.hpp"
-
-namespace apache
-{
-  namespace activemq
-  {
-    namespace client
-    {
-      namespace marshal
-      {
-        using namespace ifr ;
-        using namespace apache::activemq::client::command;
-        using namespace apache::activemq::client::io;
-
-/*
- *
- */
-class SessionInfoMarshaller : public BaseCommandMarshaller
-{
-public:
-    SessionInfoMarshaller() ;
-    virtual ~SessionInfoMarshaller() ;
-
-    virtual DataStructure* createCommand() ;
-    virtual byte getDataStructureType() ;
-    
-    virtual void unmarshal(OpenWireFormat& wireFormat, Object o, BinaryReader& dataIn, BooleanStream& bs) ;
-    virtual int marshal1(OpenWireFormat& wireFormat, Object& o, BooleanStream& bs) ;
-    virtual void marshal2(OpenWireFormat& wireFormat, Object& o, BinaryWriter& dataOut, BooleanStream& bs) ;
-} ;
-
-/* namespace */
-     }
-    }
-  }
-}
-#endif /*SessionInfoMarshaller_hpp_*/
+/*
* Copyright 2006 The Apache Software Foundation or its licensors, as
* applicable.
*
* Licensed under the Apache License, Version 2.0 (the "License");
* you may not use this file except in compliance with the License.
* You may obtain a copy of the License at
*
*     http://www.apache.org/licenses/LICENSE-2.0
*
* Unless required by applicable law or agreed to in writing, software
* distributed under the License is distributed on an "AS IS" BASIS,
* WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
* See the License for the specific language governing permissions and
* limitations under the License.
*/
#ifndef SessionInfoMarshaller_hpp_
#define SessionInfoMarshaller_hpp_

#include <string>

#include "command/DataStructure.hpp"

/* we could cut this down  - for now include all possible headers */
#include "command/BrokerId.hpp"
#include "command/ConnectionId.hpp"
#include "command/ConsumerId.hpp"
#include "command/ProducerId.hpp"
#include "command/Ses
 sionId.hpp"

#include "io/BinaryReader.hpp"
#include "io/BinaryWriter.hpp"

#include "command/BaseCommandMarshaller.hpp"
#include "util/ifr/p.hpp"

namespace apache
{
  namespace activemq
  {
    namespace client
    {
      namespace marshal
      {
        using namespace ifr ;
        using namespace apache::activemq::client::command;
        using namespace apache::activemq::client::io;

/*
 *
 */
class SessionInfoMarshaller : public BaseCommandMarshaller
{
public:
    SessionInfoMarshaller() ;
    virtual ~SessionInfoMarshaller() ;

    virtual DataStructure* createCommand() ;
    virtual byte getDataStructureType() ;
    
    virtual void unmarshal(OpenWireFormat& wireFormat, Object o, BinaryReader& dataIn, BooleanStream& bs) ;
    virtual int marshal1(OpenWireFormat& wireFormat, Object& o, BooleanStream& bs) ;
    virtual void marshal2(OpenWireFormat& wireFormat, Object& o, BinaryWriter& dataOut, BooleanStream& bs) ;
} ;

/* namespace */
     }
    }
  }
}
#endif /*Se
 ssionInfoMarshaller_hpp_*/
\ No newline at end of file

Modified: incubator/activemq/trunk/openwire-cpp/src/marshal/ShutdownInfoMarshaller.hpp
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/openwire-cpp/src/marshal/ShutdownInfoMarshaller.hpp?rev=383749&r1=383748&r2=383749&view=diff
==============================================================================
--- incubator/activemq/trunk/openwire-cpp/src/marshal/ShutdownInfoMarshaller.hpp (original)
+++ incubator/activemq/trunk/openwire-cpp/src/marshal/ShutdownInfoMarshaller.hpp Mon Mar  6 18:32:50 2006
@@ -1,71 +1 @@
-/*
-* Copyright 2006 The Apache Software Foundation or its licensors, as
-* applicable.
-*
-* Licensed under the Apache License, Version 2.0 (the "License");
-* you may not use this file except in compliance with the License.
-* You may obtain a copy of the License at
-*
-*     http://www.apache.org/licenses/LICENSE-2.0
-*
-* Unless required by applicable law or agreed to in writing, software
-* distributed under the License is distributed on an "AS IS" BASIS,
-* WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-* See the License for the specific language governing permissions and
-* limitations under the License.
-*/
-#ifndef ShutdownInfoMarshaller_hpp_
-#define ShutdownInfoMarshaller_hpp_
-
-#include <string>
-
-#include "command/DataStructure.hpp"
-
-/* we could cut this down  - for now include all possible headers */
-#include "command/BrokerId.hpp"
-#include "command/ConnectionId.hpp"
-#include "command/ConsumerId.hpp"
-#include "command/ProducerId.hpp"
-#include "command/SessionId.hpp"
-
-#include "io/BinaryReader.hpp"
-#include "io/BinaryWriter.hpp"
-
-#include "command/BaseCommandMarshaller.hpp"
-#include "util/ifr/p.hpp"
-
-namespace apache
-{
-  namespace activemq
-  {
-    namespace client
-    {
-      namespace marshal
-      {
-        using namespace ifr ;
-        using namespace apache::activemq::client::command;
-        using namespace apache::activemq::client::io;
-
-/*
- *
- */
-class ShutdownInfoMarshaller : public BaseCommandMarshaller
-{
-public:
-    ShutdownInfoMarshaller() ;
-    virtual ~ShutdownInfoMarshaller() ;
-
-    virtual DataStructure* createCommand() ;
-    virtual byte getDataStructureType() ;
-    
-    virtual void unmarshal(OpenWireFormat& wireFormat, Object o, BinaryReader& dataIn, BooleanStream& bs) ;
-    virtual int marshal1(OpenWireFormat& wireFormat, Object& o, BooleanStream& bs) ;
-    virtual void marshal2(OpenWireFormat& wireFormat, Object& o, BinaryWriter& dataOut, BooleanStream& bs) ;
-} ;
-
-/* namespace */
-     }
-    }
-  }
-}
-#endif /*ShutdownInfoMarshaller_hpp_*/
+/*
* Copyright 2006 The Apache Software Foundation or its licensors, as
* applicable.
*
* Licensed under the Apache License, Version 2.0 (the "License");
* you may not use this file except in compliance with the License.
* You may obtain a copy of the License at
*
*     http://www.apache.org/licenses/LICENSE-2.0
*
* Unless required by applicable law or agreed to in writing, software
* distributed under the License is distributed on an "AS IS" BASIS,
* WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
* See the License for the specific language governing permissions and
* limitations under the License.
*/
#ifndef ShutdownInfoMarshaller_hpp_
#define ShutdownInfoMarshaller_hpp_

#include <string>

#include "command/DataStructure.hpp"

/* we could cut this down  - for now include all possible headers */
#include "command/BrokerId.hpp"
#include "command/ConnectionId.hpp"
#include "command/ConsumerId.hpp"
#include "command/ProducerId.hpp"
#include "command/S
 essionId.hpp"

#include "io/BinaryReader.hpp"
#include "io/BinaryWriter.hpp"

#include "command/BaseCommandMarshaller.hpp"
#include "util/ifr/p.hpp"

namespace apache
{
  namespace activemq
  {
    namespace client
    {
      namespace marshal
      {
        using namespace ifr ;
        using namespace apache::activemq::client::command;
        using namespace apache::activemq::client::io;

/*
 *
 */
class ShutdownInfoMarshaller : public BaseCommandMarshaller
{
public:
    ShutdownInfoMarshaller() ;
    virtual ~ShutdownInfoMarshaller() ;

    virtual DataStructure* createCommand() ;
    virtual byte getDataStructureType() ;
    
    virtual void unmarshal(OpenWireFormat& wireFormat, Object o, BinaryReader& dataIn, BooleanStream& bs) ;
    virtual int marshal1(OpenWireFormat& wireFormat, Object& o, BooleanStream& bs) ;
    virtual void marshal2(OpenWireFormat& wireFormat, Object& o, BinaryWriter& dataOut, BooleanStream& bs) ;
} ;

/* namespace */
     }
    }
  }
}
#endif
  /*ShutdownInfoMarshaller_hpp_*/
\ No newline at end of file

Modified: incubator/activemq/trunk/openwire-cpp/src/marshal/SubscriptionInfoMarshaller.cpp
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/openwire-cpp/src/marshal/SubscriptionInfoMarshaller.cpp?rev=383749&r1=383748&r2=383749&view=diff
==============================================================================
--- incubator/activemq/trunk/openwire-cpp/src/marshal/SubscriptionInfoMarshaller.cpp (original)
+++ incubator/activemq/trunk/openwire-cpp/src/marshal/SubscriptionInfoMarshaller.cpp Mon Mar  6 18:32:50 2006
@@ -57,7 +57,7 @@
 
     SubscriptionInfo& info = (SubscriptionInfo&) o;
         info.setClientId(tightUnmarshalString(dataIn, bs));
-        info.setDestination((ActiveMQDestination) tightUnmarsalCachedObject(wireFormat, dataIn, bs));
+        info.setDestination((org.apache.activemq.command.ActiveMQDestination) tightUnmarsalCachedObject(wireFormat, dataIn, bs));
         info.setSelector(tightUnmarshalString(dataIn, bs));
         info.setSubcriptionName(tightUnmarshalString(dataIn, bs));
 

Modified: incubator/activemq/trunk/openwire-cpp/src/marshal/SubscriptionInfoMarshaller.hpp
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/openwire-cpp/src/marshal/SubscriptionInfoMarshaller.hpp?rev=383749&r1=383748&r2=383749&view=diff
==============================================================================
--- incubator/activemq/trunk/openwire-cpp/src/marshal/SubscriptionInfoMarshaller.hpp (original)
+++ incubator/activemq/trunk/openwire-cpp/src/marshal/SubscriptionInfoMarshaller.hpp Mon Mar  6 18:32:50 2006
@@ -1,71 +1 @@
-/*
-* Copyright 2006 The Apache Software Foundation or its licensors, as
-* applicable.
-*
-* Licensed under the Apache License, Version 2.0 (the "License");
-* you may not use this file except in compliance with the License.
-* You may obtain a copy of the License at
-*
-*     http://www.apache.org/licenses/LICENSE-2.0
-*
-* Unless required by applicable law or agreed to in writing, software
-* distributed under the License is distributed on an "AS IS" BASIS,
-* WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-* See the License for the specific language governing permissions and
-* limitations under the License.
-*/
-#ifndef SubscriptionInfoMarshaller_hpp_
-#define SubscriptionInfoMarshaller_hpp_
-
-#include <string>
-
-#include "command/DataStructure.hpp"
-
-/* we could cut this down  - for now include all possible headers */
-#include "command/BrokerId.hpp"
-#include "command/ConnectionId.hpp"
-#include "command/ConsumerId.hpp"
-#include "command/ProducerId.hpp"
-#include "command/SessionId.hpp"
-
-#include "io/BinaryReader.hpp"
-#include "io/BinaryWriter.hpp"
-
-#include "command/BaseDataStreamMarshaller.hpp"
-#include "util/ifr/p.hpp"
-
-namespace apache
-{
-  namespace activemq
-  {
-    namespace client
-    {
-      namespace marshal
-      {
-        using namespace ifr ;
-        using namespace apache::activemq::client::command;
-        using namespace apache::activemq::client::io;
-
-/*
- *
- */
-class SubscriptionInfoMarshaller : public BaseDataStreamMarshaller
-{
-public:
-    SubscriptionInfoMarshaller() ;
-    virtual ~SubscriptionInfoMarshaller() ;
-
-    virtual DataStructure* createCommand() ;
-    virtual byte getDataStructureType() ;
-    
-    virtual void unmarshal(OpenWireFormat& wireFormat, Object o, BinaryReader& dataIn, BooleanStream& bs) ;
-    virtual int marshal1(OpenWireFormat& wireFormat, Object& o, BooleanStream& bs) ;
-    virtual void marshal2(OpenWireFormat& wireFormat, Object& o, BinaryWriter& dataOut, BooleanStream& bs) ;
-} ;
-
-/* namespace */
-     }
-    }
-  }
-}
-#endif /*SubscriptionInfoMarshaller_hpp_*/
+/*
* Copyright 2006 The Apache Software Foundation or its licensors, as
* applicable.
*
* Licensed under the Apache License, Version 2.0 (the "License");
* you may not use this file except in compliance with the License.
* You may obtain a copy of the License at
*
*     http://www.apache.org/licenses/LICENSE-2.0
*
* Unless required by applicable law or agreed to in writing, software
* distributed under the License is distributed on an "AS IS" BASIS,
* WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
* See the License for the specific language governing permissions and
* limitations under the License.
*/
#ifndef SubscriptionInfoMarshaller_hpp_
#define SubscriptionInfoMarshaller_hpp_

#include <string>

#include "command/DataStructure.hpp"

/* we could cut this down  - for now include all possible headers */
#include "command/BrokerId.hpp"
#include "command/ConnectionId.hpp"
#include "command/ConsumerId.hpp"
#include "command/ProducerId.hpp"
#include "c
 ommand/SessionId.hpp"

#include "io/BinaryReader.hpp"
#include "io/BinaryWriter.hpp"

#include "command/BaseDataStreamMarshaller.hpp"
#include "util/ifr/p.hpp"

namespace apache
{
  namespace activemq
  {
    namespace client
    {
      namespace marshal
      {
        using namespace ifr ;
        using namespace apache::activemq::client::command;
        using namespace apache::activemq::client::io;

/*
 *
 */
class SubscriptionInfoMarshaller : public BaseDataStreamMarshaller
{
public:
    SubscriptionInfoMarshaller() ;
    virtual ~SubscriptionInfoMarshaller() ;

    virtual DataStructure* createCommand() ;
    virtual byte getDataStructureType() ;
    
    virtual void unmarshal(OpenWireFormat& wireFormat, Object o, BinaryReader& dataIn, BooleanStream& bs) ;
    virtual int marshal1(OpenWireFormat& wireFormat, Object& o, BooleanStream& bs) ;
    virtual void marshal2(OpenWireFormat& wireFormat, Object& o, BinaryWriter& dataOut, BooleanStream& bs) ;
} ;

/* namespace */
 
     }
    }
  }
}
#endif /*SubscriptionInfoMarshaller_hpp_*/
\ No newline at end of file

Modified: incubator/activemq/trunk/openwire-cpp/src/marshal/TransactionIdMarshaller.hpp
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/openwire-cpp/src/marshal/TransactionIdMarshaller.hpp?rev=383749&r1=383748&r2=383749&view=diff
==============================================================================
--- incubator/activemq/trunk/openwire-cpp/src/marshal/TransactionIdMarshaller.hpp (original)
+++ incubator/activemq/trunk/openwire-cpp/src/marshal/TransactionIdMarshaller.hpp Mon Mar  6 18:32:50 2006
@@ -1,71 +1 @@
-/*
-* Copyright 2006 The Apache Software Foundation or its licensors, as
-* applicable.
-*
-* Licensed under the Apache License, Version 2.0 (the "License");
-* you may not use this file except in compliance with the License.
-* You may obtain a copy of the License at
-*
-*     http://www.apache.org/licenses/LICENSE-2.0
-*
-* Unless required by applicable law or agreed to in writing, software
-* distributed under the License is distributed on an "AS IS" BASIS,
-* WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-* See the License for the specific language governing permissions and
-* limitations under the License.
-*/
-#ifndef TransactionIdMarshaller_hpp_
-#define TransactionIdMarshaller_hpp_
-
-#include <string>
-
-#include "command/DataStructure.hpp"
-
-/* we could cut this down  - for now include all possible headers */
-#include "command/BrokerId.hpp"
-#include "command/ConnectionId.hpp"
-#include "command/ConsumerId.hpp"
-#include "command/ProducerId.hpp"
-#include "command/SessionId.hpp"
-
-#include "io/BinaryReader.hpp"
-#include "io/BinaryWriter.hpp"
-
-#include "command/BaseDataStreamMarshaller.hpp"
-#include "util/ifr/p.hpp"
-
-namespace apache
-{
-  namespace activemq
-  {
-    namespace client
-    {
-      namespace marshal
-      {
-        using namespace ifr ;
-        using namespace apache::activemq::client::command;
-        using namespace apache::activemq::client::io;
-
-/*
- *
- */
-class TransactionIdMarshaller : public BaseDataStreamMarshaller
-{
-public:
-    TransactionIdMarshaller() ;
-    virtual ~TransactionIdMarshaller() ;
-
-    virtual DataStructure* createCommand() ;
-    virtual byte getDataStructureType() ;
-    
-    virtual void unmarshal(OpenWireFormat& wireFormat, Object o, BinaryReader& dataIn, BooleanStream& bs) ;
-    virtual int marshal1(OpenWireFormat& wireFormat, Object& o, BooleanStream& bs) ;
-    virtual void marshal2(OpenWireFormat& wireFormat, Object& o, BinaryWriter& dataOut, BooleanStream& bs) ;
-} ;
-
-/* namespace */
-     }
-    }
-  }
-}
-#endif /*TransactionIdMarshaller_hpp_*/
+/*
* Copyright 2006 The Apache Software Foundation or its licensors, as
* applicable.
*
* Licensed under the Apache License, Version 2.0 (the "License");
* you may not use this file except in compliance with the License.
* You may obtain a copy of the License at
*
*     http://www.apache.org/licenses/LICENSE-2.0
*
* Unless required by applicable law or agreed to in writing, software
* distributed under the License is distributed on an "AS IS" BASIS,
* WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
* See the License for the specific language governing permissions and
* limitations under the License.
*/
#ifndef TransactionIdMarshaller_hpp_
#define TransactionIdMarshaller_hpp_

#include <string>

#include "command/DataStructure.hpp"

/* we could cut this down  - for now include all possible headers */
#include "command/BrokerId.hpp"
#include "command/ConnectionId.hpp"
#include "command/ConsumerId.hpp"
#include "command/ProducerId.hpp"
#include "command
 /SessionId.hpp"

#include "io/BinaryReader.hpp"
#include "io/BinaryWriter.hpp"

#include "command/BaseDataStreamMarshaller.hpp"
#include "util/ifr/p.hpp"

namespace apache
{
  namespace activemq
  {
    namespace client
    {
      namespace marshal
      {
        using namespace ifr ;
        using namespace apache::activemq::client::command;
        using namespace apache::activemq::client::io;

/*
 *
 */
class TransactionIdMarshaller : public BaseDataStreamMarshaller
{
public:
    TransactionIdMarshaller() ;
    virtual ~TransactionIdMarshaller() ;

    virtual DataStructure* createCommand() ;
    virtual byte getDataStructureType() ;
    
    virtual void unmarshal(OpenWireFormat& wireFormat, Object o, BinaryReader& dataIn, BooleanStream& bs) ;
    virtual int marshal1(OpenWireFormat& wireFormat, Object& o, BooleanStream& bs) ;
    virtual void marshal2(OpenWireFormat& wireFormat, Object& o, BinaryWriter& dataOut, BooleanStream& bs) ;
} ;

/* namespace */
     }
    }
 
  }
}
#endif /*TransactionIdMarshaller_hpp_*/
\ No newline at end of file

Modified: incubator/activemq/trunk/openwire-cpp/src/marshal/TransactionInfoMarshaller.cpp
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/openwire-cpp/src/marshal/TransactionInfoMarshaller.cpp?rev=383749&r1=383748&r2=383749&view=diff
==============================================================================
--- incubator/activemq/trunk/openwire-cpp/src/marshal/TransactionInfoMarshaller.cpp (original)
+++ incubator/activemq/trunk/openwire-cpp/src/marshal/TransactionInfoMarshaller.cpp Mon Mar  6 18:32:50 2006
@@ -56,8 +56,8 @@
     base.unmarshal(wireFormat, o, dataIn, bs);
 
     TransactionInfo& info = (TransactionInfo&) o;
-        info.setConnectionId((ConnectionId) tightUnmarsalCachedObject(wireFormat, dataIn, bs));
-        info.setTransactionId((TransactionId) tightUnmarsalCachedObject(wireFormat, dataIn, bs));
+        info.setConnectionId((org.apache.activemq.command.ConnectionId) tightUnmarsalCachedObject(wireFormat, dataIn, bs));
+        info.setTransactionId((org.apache.activemq.command.TransactionId) tightUnmarsalCachedObject(wireFormat, dataIn, bs));
         info.setType(dataIn.readByte());
 
 }

Modified: incubator/activemq/trunk/openwire-cpp/src/marshal/TransactionInfoMarshaller.hpp
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/openwire-cpp/src/marshal/TransactionInfoMarshaller.hpp?rev=383749&r1=383748&r2=383749&view=diff
==============================================================================
--- incubator/activemq/trunk/openwire-cpp/src/marshal/TransactionInfoMarshaller.hpp (original)
+++ incubator/activemq/trunk/openwire-cpp/src/marshal/TransactionInfoMarshaller.hpp Mon Mar  6 18:32:50 2006
@@ -1,71 +1 @@
-/*
-* Copyright 2006 The Apache Software Foundation or its licensors, as
-* applicable.
-*
-* Licensed under the Apache License, Version 2.0 (the "License");
-* you may not use this file except in compliance with the License.
-* You may obtain a copy of the License at
-*
-*     http://www.apache.org/licenses/LICENSE-2.0
-*
-* Unless required by applicable law or agreed to in writing, software
-* distributed under the License is distributed on an "AS IS" BASIS,
-* WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-* See the License for the specific language governing permissions and
-* limitations under the License.
-*/
-#ifndef TransactionInfoMarshaller_hpp_
-#define TransactionInfoMarshaller_hpp_
-
-#include <string>
-
-#include "command/DataStructure.hpp"
-
-/* we could cut this down  - for now include all possible headers */
-#include "command/BrokerId.hpp"
-#include "command/ConnectionId.hpp"
-#include "command/ConsumerId.hpp"
-#include "command/ProducerId.hpp"
-#include "command/SessionId.hpp"
-
-#include "io/BinaryReader.hpp"
-#include "io/BinaryWriter.hpp"
-
-#include "command/BaseCommandMarshaller.hpp"
-#include "util/ifr/p.hpp"
-
-namespace apache
-{
-  namespace activemq
-  {
-    namespace client
-    {
-      namespace marshal
-      {
-        using namespace ifr ;
-        using namespace apache::activemq::client::command;
-        using namespace apache::activemq::client::io;
-
-/*
- *
- */
-class TransactionInfoMarshaller : public BaseCommandMarshaller
-{
-public:
-    TransactionInfoMarshaller() ;
-    virtual ~TransactionInfoMarshaller() ;
-
-    virtual DataStructure* createCommand() ;
-    virtual byte getDataStructureType() ;
-    
-    virtual void unmarshal(OpenWireFormat& wireFormat, Object o, BinaryReader& dataIn, BooleanStream& bs) ;
-    virtual int marshal1(OpenWireFormat& wireFormat, Object& o, BooleanStream& bs) ;
-    virtual void marshal2(OpenWireFormat& wireFormat, Object& o, BinaryWriter& dataOut, BooleanStream& bs) ;
-} ;
-
-/* namespace */
-     }
-    }
-  }
-}
-#endif /*TransactionInfoMarshaller_hpp_*/
+/*
* Copyright 2006 The Apache Software Foundation or its licensors, as
* applicable.
*
* Licensed under the Apache License, Version 2.0 (the "License");
* you may not use this file except in compliance with the License.
* You may obtain a copy of the License at
*
*     http://www.apache.org/licenses/LICENSE-2.0
*
* Unless required by applicable law or agreed to in writing, software
* distributed under the License is distributed on an "AS IS" BASIS,
* WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
* See the License for the specific language governing permissions and
* limitations under the License.
*/
#ifndef TransactionInfoMarshaller_hpp_
#define TransactionInfoMarshaller_hpp_

#include <string>

#include "command/DataStructure.hpp"

/* we could cut this down  - for now include all possible headers */
#include "command/BrokerId.hpp"
#include "command/ConnectionId.hpp"
#include "command/ConsumerId.hpp"
#include "command/ProducerId.hpp"
#include "com
 mand/SessionId.hpp"

#include "io/BinaryReader.hpp"
#include "io/BinaryWriter.hpp"

#include "command/BaseCommandMarshaller.hpp"
#include "util/ifr/p.hpp"

namespace apache
{
  namespace activemq
  {
    namespace client
    {
      namespace marshal
      {
        using namespace ifr ;
        using namespace apache::activemq::client::command;
        using namespace apache::activemq::client::io;

/*
 *
 */
class TransactionInfoMarshaller : public BaseCommandMarshaller
{
public:
    TransactionInfoMarshaller() ;
    virtual ~TransactionInfoMarshaller() ;

    virtual DataStructure* createCommand() ;
    virtual byte getDataStructureType() ;
    
    virtual void unmarshal(OpenWireFormat& wireFormat, Object o, BinaryReader& dataIn, BooleanStream& bs) ;
    virtual int marshal1(OpenWireFormat& wireFormat, Object& o, BooleanStream& bs) ;
    virtual void marshal2(OpenWireFormat& wireFormat, Object& o, BinaryWriter& dataOut, BooleanStream& bs) ;
} ;

/* namespace */
     }
   
  }
  }
}
#endif /*TransactionInfoMarshaller_hpp_*/
\ No newline at end of file

Modified: incubator/activemq/trunk/openwire-cpp/src/marshal/WireFormatInfoMarshaller.cpp
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/openwire-cpp/src/marshal/WireFormatInfoMarshaller.cpp?rev=383749&r1=383748&r2=383749&view=diff
==============================================================================
--- incubator/activemq/trunk/openwire-cpp/src/marshal/WireFormatInfoMarshaller.cpp (original)
+++ incubator/activemq/trunk/openwire-cpp/src/marshal/WireFormatInfoMarshaller.cpp Mon Mar  6 18:32:50 2006
@@ -58,11 +58,7 @@
     WireFormatInfo& info = (WireFormatInfo&) o;
         info.setMagic(tightUnmarshalConstByteArray(dataIn, bs, 8));
         info.setVersion(dataIn.readInt());
-        info.setCacheEnabled(bs.readBoolean());
-        info.setStackTraceEnabled(bs.readBoolean());
-        info.setTcpNoDelayEnabled(bs.readBoolean());
-        info.setPrefixPacketSize(bs.readBoolean());
-        info.setTightEncodingEnabled(bs.readBoolean());
+        info.setMarshalledProperties(tightUnmarshalByteSequence(dataIn, bs));
 
 }
 
@@ -74,11 +70,8 @@
     WireFormatInfo& info = (WireFormatInfo&) o;
 
     int rc = base.marshal1(wireFormat, info, bs);
-            bs.writeBoolean(info.isCacheEnabled());
-    bs.writeBoolean(info.isStackTraceEnabled());
-    bs.writeBoolean(info.isTcpNoDelayEnabled());
-    bs.writeBoolean(info.isPrefixPacketSize());
-    bs.writeBoolean(info.isTightEncodingEnabled());
+            bs.writeBoolean(info.getMarshalledProperties()!=null);
+    rc += info.getMarshalledProperties()==null ? 0 : info.getMarshalledProperties().Length+4;
 
     return rc + 9;
 }
@@ -92,10 +85,9 @@
     WireFormatInfo& info = (WireFormatInfo&) o;
     dataOut.write(info.getMagic(), 0, 8);
     DataStreamMarshaller.writeInt(info.getVersion(), dataOut);
-    bs.readBoolean();
-    bs.readBoolean();
-    bs.readBoolean();
-    bs.readBoolean();
-    bs.readBoolean();
+    if(bs.readBoolean()) {
+       DataStreamMarshaller.writeInt(info.getMarshalledProperties().Length, dataOut);
+       dataOut.write(info.getMarshalledProperties());
+    }
 
 }

Modified: incubator/activemq/trunk/openwire-cpp/src/marshal/WireFormatInfoMarshaller.hpp
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/openwire-cpp/src/marshal/WireFormatInfoMarshaller.hpp?rev=383749&r1=383748&r2=383749&view=diff
==============================================================================
--- incubator/activemq/trunk/openwire-cpp/src/marshal/WireFormatInfoMarshaller.hpp (original)
+++ incubator/activemq/trunk/openwire-cpp/src/marshal/WireFormatInfoMarshaller.hpp Mon Mar  6 18:32:50 2006
@@ -1,71 +1 @@
-/*
-* Copyright 2006 The Apache Software Foundation or its licensors, as
-* applicable.
-*
-* Licensed under the Apache License, Version 2.0 (the "License");
-* you may not use this file except in compliance with the License.
-* You may obtain a copy of the License at
-*
-*     http://www.apache.org/licenses/LICENSE-2.0
-*
-* Unless required by applicable law or agreed to in writing, software
-* distributed under the License is distributed on an "AS IS" BASIS,
-* WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-* See the License for the specific language governing permissions and
-* limitations under the License.
-*/
-#ifndef WireFormatInfoMarshaller_hpp_
-#define WireFormatInfoMarshaller_hpp_
-
-#include <string>
-
-#include "command/DataStructure.hpp"
-
-/* we could cut this down  - for now include all possible headers */
-#include "command/BrokerId.hpp"
-#include "command/ConnectionId.hpp"
-#include "command/ConsumerId.hpp"
-#include "command/ProducerId.hpp"
-#include "command/SessionId.hpp"
-
-#include "io/BinaryReader.hpp"
-#include "io/BinaryWriter.hpp"
-
-#include "command/BaseDataStreamMarshaller.hpp"
-#include "util/ifr/p.hpp"
-
-namespace apache
-{
-  namespace activemq
-  {
-    namespace client
-    {
-      namespace marshal
-      {
-        using namespace ifr ;
-        using namespace apache::activemq::client::command;
-        using namespace apache::activemq::client::io;
-
-/*
- *
- */
-class WireFormatInfoMarshaller : public BaseDataStreamMarshaller
-{
-public:
-    WireFormatInfoMarshaller() ;
-    virtual ~WireFormatInfoMarshaller() ;
-
-    virtual DataStructure* createCommand() ;
-    virtual byte getDataStructureType() ;
-    
-    virtual void unmarshal(OpenWireFormat& wireFormat, Object o, BinaryReader& dataIn, BooleanStream& bs) ;
-    virtual int marshal1(OpenWireFormat& wireFormat, Object& o, BooleanStream& bs) ;
-    virtual void marshal2(OpenWireFormat& wireFormat, Object& o, BinaryWriter& dataOut, BooleanStream& bs) ;
-} ;
-
-/* namespace */
-     }
-    }
-  }
-}
-#endif /*WireFormatInfoMarshaller_hpp_*/
+/*
* Copyright 2006 The Apache Software Foundation or its licensors, as
* applicable.
*
* Licensed under the Apache License, Version 2.0 (the "License");
* you may not use this file except in compliance with the License.
* You may obtain a copy of the License at
*
*     http://www.apache.org/licenses/LICENSE-2.0
*
* Unless required by applicable law or agreed to in writing, software
* distributed under the License is distributed on an "AS IS" BASIS,
* WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
* See the License for the specific language governing permissions and
* limitations under the License.
*/
#ifndef WireFormatInfoMarshaller_hpp_
#define WireFormatInfoMarshaller_hpp_

#include <string>

#include "command/DataStructure.hpp"

/* we could cut this down  - for now include all possible headers */
#include "command/BrokerId.hpp"
#include "command/ConnectionId.hpp"
#include "command/ConsumerId.hpp"
#include "command/ProducerId.hpp"
#include "comma
 nd/SessionId.hpp"

#include "io/BinaryReader.hpp"
#include "io/BinaryWriter.hpp"

#include "command/BaseDataStreamMarshaller.hpp"
#include "util/ifr/p.hpp"

namespace apache
{
  namespace activemq
  {
    namespace client
    {
      namespace marshal
      {
        using namespace ifr ;
        using namespace apache::activemq::client::command;
        using namespace apache::activemq::client::io;

/*
 *
 */
class WireFormatInfoMarshaller : public BaseDataStreamMarshaller
{
public:
    WireFormatInfoMarshaller() ;
    virtual ~WireFormatInfoMarshaller() ;

    virtual DataStructure* createCommand() ;
    virtual byte getDataStructureType() ;
    
    virtual void unmarshal(OpenWireFormat& wireFormat, Object o, BinaryReader& dataIn, BooleanStream& bs) ;
    virtual int marshal1(OpenWireFormat& wireFormat, Object& o, BooleanStream& bs) ;
    virtual void marshal2(OpenWireFormat& wireFormat, Object& o, BinaryWriter& dataOut, BooleanStream& bs) ;
} ;

/* namespace */
     }
  
   }
  }
}
#endif /*WireFormatInfoMarshaller_hpp_*/
\ No newline at end of file

Modified: incubator/activemq/trunk/openwire-cpp/src/marshal/XATransactionIdMarshaller.hpp
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/openwire-cpp/src/marshal/XATransactionIdMarshaller.hpp?rev=383749&r1=383748&r2=383749&view=diff
==============================================================================
--- incubator/activemq/trunk/openwire-cpp/src/marshal/XATransactionIdMarshaller.hpp (original)
+++ incubator/activemq/trunk/openwire-cpp/src/marshal/XATransactionIdMarshaller.hpp Mon Mar  6 18:32:50 2006
@@ -1,71 +1 @@
-/*
-* Copyright 2006 The Apache Software Foundation or its licensors, as
-* applicable.
-*
-* Licensed under the Apache License, Version 2.0 (the "License");
-* you may not use this file except in compliance with the License.
-* You may obtain a copy of the License at
-*
-*     http://www.apache.org/licenses/LICENSE-2.0
-*
-* Unless required by applicable law or agreed to in writing, software
-* distributed under the License is distributed on an "AS IS" BASIS,
-* WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-* See the License for the specific language governing permissions and
-* limitations under the License.
-*/
-#ifndef XATransactionIdMarshaller_hpp_
-#define XATransactionIdMarshaller_hpp_
-
-#include <string>
-
-#include "command/DataStructure.hpp"
-
-/* we could cut this down  - for now include all possible headers */
-#include "command/BrokerId.hpp"
-#include "command/ConnectionId.hpp"
-#include "command/ConsumerId.hpp"
-#include "command/ProducerId.hpp"
-#include "command/SessionId.hpp"
-
-#include "io/BinaryReader.hpp"
-#include "io/BinaryWriter.hpp"
-
-#include "command/TransactionIdMarshaller.hpp"
-#include "util/ifr/p.hpp"
-
-namespace apache
-{
-  namespace activemq
-  {
-    namespace client
-    {
-      namespace marshal
-      {
-        using namespace ifr ;
-        using namespace apache::activemq::client::command;
-        using namespace apache::activemq::client::io;
-
-/*
- *
- */
-class XATransactionIdMarshaller : public TransactionIdMarshaller
-{
-public:
-    XATransactionIdMarshaller() ;
-    virtual ~XATransactionIdMarshaller() ;
-
-    virtual DataStructure* createCommand() ;
-    virtual byte getDataStructureType() ;
-    
-    virtual void unmarshal(OpenWireFormat& wireFormat, Object o, BinaryReader& dataIn, BooleanStream& bs) ;
-    virtual int marshal1(OpenWireFormat& wireFormat, Object& o, BooleanStream& bs) ;
-    virtual void marshal2(OpenWireFormat& wireFormat, Object& o, BinaryWriter& dataOut, BooleanStream& bs) ;
-} ;
-
-/* namespace */
-     }
-    }
-  }
-}
-#endif /*XATransactionIdMarshaller_hpp_*/
+/*
* Copyright 2006 The Apache Software Foundation or its licensors, as
* applicable.
*
* Licensed under the Apache License, Version 2.0 (the "License");
* you may not use this file except in compliance with the License.
* You may obtain a copy of the License at
*
*     http://www.apache.org/licenses/LICENSE-2.0
*
* Unless required by applicable law or agreed to in writing, software
* distributed under the License is distributed on an "AS IS" BASIS,
* WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
* See the License for the specific language governing permissions and
* limitations under the License.
*/
#ifndef XATransactionIdMarshaller_hpp_
#define XATransactionIdMarshaller_hpp_

#include <string>

#include "command/DataStructure.hpp"

/* we could cut this down  - for now include all possible headers */
#include "command/BrokerId.hpp"
#include "command/ConnectionId.hpp"
#include "command/ConsumerId.hpp"
#include "command/ProducerId.hpp"
#include "com
 mand/SessionId.hpp"

#include "io/BinaryReader.hpp"
#include "io/BinaryWriter.hpp"

#include "command/TransactionIdMarshaller.hpp"
#include "util/ifr/p.hpp"

namespace apache
{
  namespace activemq
  {
    namespace client
    {
      namespace marshal
      {
        using namespace ifr ;
        using namespace apache::activemq::client::command;
        using namespace apache::activemq::client::io;

/*
 *
 */
class XATransactionIdMarshaller : public TransactionIdMarshaller
{
public:
    XATransactionIdMarshaller() ;
    virtual ~XATransactionIdMarshaller() ;

    virtual DataStructure* createCommand() ;
    virtual byte getDataStructureType() ;
    
    virtual void unmarshal(OpenWireFormat& wireFormat, Object o, BinaryReader& dataIn, BooleanStream& bs) ;
    virtual int marshal1(OpenWireFormat& wireFormat, Object& o, BooleanStream& bs) ;
    virtual void marshal2(OpenWireFormat& wireFormat, Object& o, BinaryWriter& dataOut, BooleanStream& bs) ;
} ;

/* namespace */
     }
 
    }
  }
}
#endif /*XATransactionIdMarshaller_hpp_*/
\ No newline at end of file