You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@activemq.apache.org by ta...@apache.org on 2013/03/24 22:30:56 UTC

svn commit: r1460467 [13/15] - in /activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq: commands/ wireformat/openwire/marshal/generated/

Modified: activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/wireformat/openwire/marshal/generated/MessageMarshaller.cpp
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/wireformat/openwire/marshal/generated/MessageMarshaller.cpp?rev=1460467&r1=1460466&r2=1460467&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/wireformat/openwire/marshal/generated/MessageMarshaller.cpp (original)
+++ activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/wireformat/openwire/marshal/generated/MessageMarshaller.cpp Sun Mar 24 21:30:52 2013
@@ -41,348 +41,348 @@ using namespace decaf::io;
 using namespace decaf::lang;
 
 ///////////////////////////////////////////////////////////////////////////////
-void MessageMarshaller::tightUnmarshal( OpenWireFormat* wireFormat, DataStructure* dataStructure, DataInputStream* dataIn, BooleanStream* bs ) {
+void MessageMarshaller::tightUnmarshal(OpenWireFormat* wireFormat, DataStructure* dataStructure, DataInputStream* dataIn, BooleanStream* bs) {
 
     try {
 
-        BaseCommandMarshaller::tightUnmarshal( wireFormat, dataStructure, dataIn, bs );
+        BaseCommandMarshaller::tightUnmarshal(wireFormat, dataStructure, dataIn, bs);
 
         Message* info =
-            dynamic_cast<Message*>( dataStructure );
+            dynamic_cast<Message*>(dataStructure);
 
         int wireVersion = wireFormat->getVersion();
 
-        info->setProducerId( Pointer<ProducerId>( dynamic_cast< ProducerId* >(
-            tightUnmarshalCachedObject( wireFormat, dataIn, bs ) ) ) );
-        info->setDestination( Pointer<ActiveMQDestination>( dynamic_cast< ActiveMQDestination* >(
-            tightUnmarshalCachedObject( wireFormat, dataIn, bs ) ) ) );
-        info->setTransactionId( Pointer<TransactionId>( dynamic_cast< TransactionId* >(
-            tightUnmarshalCachedObject( wireFormat, dataIn, bs ) ) ) );
-        info->setOriginalDestination( Pointer<ActiveMQDestination>( dynamic_cast< ActiveMQDestination* >(
-            tightUnmarshalCachedObject( wireFormat, dataIn, bs ) ) ) );
-        info->setMessageId( Pointer<MessageId>( dynamic_cast< MessageId* >(
-            tightUnmarshalNestedObject( wireFormat, dataIn, bs ) ) ) );
-        info->setOriginalTransactionId( Pointer<TransactionId>( dynamic_cast< TransactionId* >(
-            tightUnmarshalCachedObject( 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( Pointer<ActiveMQDestination>( dynamic_cast< ActiveMQDestination* >(
-            tightUnmarshalNestedObject( wireFormat, dataIn, bs ) ) ) );
-        info->setTimestamp( tightUnmarshalLong( wireFormat, dataIn, bs ) );
-        info->setType( tightUnmarshalString( dataIn, bs ) );
-        info->setContent( tightUnmarshalByteArray( dataIn, bs ) );
-        info->setMarshalledProperties( tightUnmarshalByteArray( dataIn, bs ) );
-        info->setDataStructure( Pointer<DataStructure>( dynamic_cast< DataStructure* >(
-            tightUnmarshalNestedObject( wireFormat, dataIn, bs ) ) ) );
-        info->setTargetConsumerId( Pointer<ConsumerId>( dynamic_cast< ConsumerId* >(
-            tightUnmarshalCachedObject( wireFormat, dataIn, bs ) ) ) );
-        info->setCompressed( bs->readBoolean() );
-        info->setRedeliveryCounter( dataIn->readInt() );
+        info->setProducerId(Pointer<ProducerId>(dynamic_cast<ProducerId* >(
+            tightUnmarshalCachedObject(wireFormat, dataIn, bs))));
+        info->setDestination(Pointer<ActiveMQDestination>(dynamic_cast<ActiveMQDestination* >(
+            tightUnmarshalCachedObject(wireFormat, dataIn, bs))));
+        info->setTransactionId(Pointer<TransactionId>(dynamic_cast<TransactionId* >(
+            tightUnmarshalCachedObject(wireFormat, dataIn, bs))));
+        info->setOriginalDestination(Pointer<ActiveMQDestination>(dynamic_cast<ActiveMQDestination* >(
+            tightUnmarshalCachedObject(wireFormat, dataIn, bs))));
+        info->setMessageId(Pointer<MessageId>(dynamic_cast<MessageId* >(
+            tightUnmarshalNestedObject(wireFormat, dataIn, bs))));
+        info->setOriginalTransactionId(Pointer<TransactionId>(dynamic_cast<TransactionId* >(
+            tightUnmarshalCachedObject(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(Pointer<ActiveMQDestination>(dynamic_cast<ActiveMQDestination* >(
+            tightUnmarshalNestedObject(wireFormat, dataIn, bs))));
+        info->setTimestamp(tightUnmarshalLong(wireFormat, dataIn, bs));
+        info->setType(tightUnmarshalString(dataIn, bs));
+        info->setContent(tightUnmarshalByteArray(dataIn, bs));
+        info->setMarshalledProperties(tightUnmarshalByteArray(dataIn, bs));
+        info->setDataStructure(Pointer<DataStructure>(dynamic_cast<DataStructure* >(
+            tightUnmarshalNestedObject(wireFormat, dataIn, bs))));
+        info->setTargetConsumerId(Pointer<ConsumerId>(dynamic_cast<ConsumerId* >(
+            tightUnmarshalCachedObject(wireFormat, dataIn, bs))));
+        info->setCompressed(bs->readBoolean());
+        info->setRedeliveryCounter(dataIn->readInt());
 
-        if( bs->readBoolean() ) {
+        if (bs->readBoolean()) {
             short size = dataIn->readShort();
-            info->getBrokerPath().reserve( size );
-            for( int i = 0; i < size; i++ ) {
-                info->getBrokerPath().push_back( Pointer<BrokerId>( dynamic_cast< BrokerId* >(
-                    tightUnmarshalNestedObject( wireFormat, dataIn, bs ) ) ) );
+            info->getBrokerPath().reserve(size);
+            for (int i = 0; i < size; i++) {
+                info->getBrokerPath().push_back(Pointer<BrokerId>(dynamic_cast<BrokerId*>(
+                    tightUnmarshalNestedObject(wireFormat, dataIn, bs))));
             }
         } else {
             info->getBrokerPath().clear();
         }
-        info->setArrival( tightUnmarshalLong( wireFormat, dataIn, bs ) );
-        info->setUserID( tightUnmarshalString( dataIn, bs ) );
-        info->setRecievedByDFBridge( bs->readBoolean() );
-        if( wireVersion >= 2 ) {
-            info->setDroppable( bs->readBoolean() );
+        info->setArrival(tightUnmarshalLong(wireFormat, dataIn, bs));
+        info->setUserID(tightUnmarshalString(dataIn, bs));
+        info->setRecievedByDFBridge(bs->readBoolean());
+        if (wireVersion >= 2) {
+            info->setDroppable(bs->readBoolean());
         }
-        if( wireVersion >= 3 ) {
+        if (wireVersion >= 3) {
 
-            if( bs->readBoolean() ) {
+            if (bs->readBoolean()) {
                 short size = dataIn->readShort();
-                info->getCluster().reserve( size );
-                for( int i = 0; i < size; i++ ) {
-                    info->getCluster().push_back( Pointer<BrokerId>( dynamic_cast< BrokerId* >(
-                        tightUnmarshalNestedObject( wireFormat, dataIn, bs ) ) ) );
+                info->getCluster().reserve(size);
+                for (int i = 0; i < size; i++) {
+                    info->getCluster().push_back(Pointer<BrokerId>(dynamic_cast<BrokerId*>(
+                        tightUnmarshalNestedObject(wireFormat, dataIn, bs))));
                 }
             } else {
                 info->getCluster().clear();
             }
         }
-        if( wireVersion >= 3 ) {
-            info->setBrokerInTime( tightUnmarshalLong( wireFormat, dataIn, bs ) );
+        if (wireVersion >= 3) {
+            info->setBrokerInTime(tightUnmarshalLong(wireFormat, dataIn, bs));
         }
-        if( wireVersion >= 3 ) {
-            info->setBrokerOutTime( tightUnmarshalLong( wireFormat, dataIn, bs ) );
+        if (wireVersion >= 3) {
+            info->setBrokerOutTime(tightUnmarshalLong(wireFormat, dataIn, bs));
         }
     }
-    AMQ_CATCH_RETHROW( decaf::io::IOException )
-    AMQ_CATCH_EXCEPTION_CONVERT( exceptions::ActiveMQException, decaf::io::IOException )
-    AMQ_CATCHALL_THROW( decaf::io::IOException )
+    AMQ_CATCH_RETHROW(decaf::io::IOException)
+    AMQ_CATCH_EXCEPTION_CONVERT(exceptions::ActiveMQException, decaf::io::IOException)
+    AMQ_CATCHALL_THROW(decaf::io::IOException)
 }
 
 ///////////////////////////////////////////////////////////////////////////////
-int MessageMarshaller::tightMarshal1( OpenWireFormat* wireFormat, DataStructure* dataStructure, BooleanStream* bs ) {
+int MessageMarshaller::tightMarshal1(OpenWireFormat* wireFormat, DataStructure* dataStructure, BooleanStream* bs) {
 
     try {
 
         Message* info =
-            dynamic_cast<Message*>( dataStructure );
+            dynamic_cast<Message*>(dataStructure);
 
-        int rc = BaseCommandMarshaller::tightMarshal1( wireFormat, dataStructure, bs );
+        int rc = BaseCommandMarshaller::tightMarshal1(wireFormat, dataStructure, bs);
 
         int wireVersion = wireFormat->getVersion();
 
-        rc += tightMarshalCachedObject1( wireFormat, info->getProducerId().get(), bs );
-        rc += tightMarshalCachedObject1( wireFormat, info->getDestination().get(), bs );
-        rc += tightMarshalCachedObject1( wireFormat, info->getTransactionId().get(), bs );
-        rc += tightMarshalCachedObject1( wireFormat, info->getOriginalDestination().get(), bs );
-        rc += tightMarshalNestedObject1( wireFormat, info->getMessageId().get(), bs );
-        rc += tightMarshalCachedObject1( wireFormat, info->getOriginalTransactionId().get(), bs );
-        rc += tightMarshalString1( info->getGroupID(), bs );
-        rc += tightMarshalString1( info->getCorrelationId(), bs );
-        bs->writeBoolean( info->isPersistent() );
-        rc += tightMarshalLong1( wireFormat, info->getExpiration(), bs );
-        rc += tightMarshalNestedObject1( wireFormat, info->getReplyTo().get(), bs );
-        rc += tightMarshalLong1( wireFormat, info->getTimestamp(), bs );
-        rc += tightMarshalString1( info->getType(), bs );
-        bs->writeBoolean( info->getContent().size() != 0 );
+        rc += tightMarshalCachedObject1(wireFormat, info->getProducerId().get(), bs);
+        rc += tightMarshalCachedObject1(wireFormat, info->getDestination().get(), bs);
+        rc += tightMarshalCachedObject1(wireFormat, info->getTransactionId().get(), bs);
+        rc += tightMarshalCachedObject1(wireFormat, info->getOriginalDestination().get(), bs);
+        rc += tightMarshalNestedObject1(wireFormat, info->getMessageId().get(), bs);
+        rc += tightMarshalCachedObject1(wireFormat, info->getOriginalTransactionId().get(), bs);
+        rc += tightMarshalString1(info->getGroupID(), bs);
+        rc += tightMarshalString1(info->getCorrelationId(), bs);
+        bs->writeBoolean(info->isPersistent());
+        rc += tightMarshalLong1(wireFormat, info->getExpiration(), bs);
+        rc += tightMarshalNestedObject1(wireFormat, info->getReplyTo().get(), bs);
+        rc += tightMarshalLong1(wireFormat, info->getTimestamp(), bs);
+        rc += tightMarshalString1(info->getType(), bs);
+        bs->writeBoolean(info->getContent().size() != 0);
         rc += info->getContent().size() == 0 ? 0 : (int)info->getContent().size() + 4;
-        bs->writeBoolean( info->getMarshalledProperties().size() != 0 );
+        bs->writeBoolean(info->getMarshalledProperties().size() != 0);
         rc += info->getMarshalledProperties().size() == 0 ? 0 : (int)info->getMarshalledProperties().size() + 4;
-        rc += tightMarshalNestedObject1( wireFormat, info->getDataStructure().get(), bs );
-        rc += tightMarshalCachedObject1( wireFormat, info->getTargetConsumerId().get(), bs );
-        bs->writeBoolean( info->isCompressed() );
-        rc += tightMarshalObjectArray1( wireFormat, info->getBrokerPath(), bs );
-        rc += tightMarshalLong1( wireFormat, info->getArrival(), bs );
-        rc += tightMarshalString1( info->getUserID(), bs );
-        bs->writeBoolean( info->isRecievedByDFBridge() );
-        if( wireVersion >= 2 ) {
-            bs->writeBoolean( info->isDroppable() );
+        rc += tightMarshalNestedObject1(wireFormat, info->getDataStructure().get(), bs);
+        rc += tightMarshalCachedObject1(wireFormat, info->getTargetConsumerId().get(), bs);
+        bs->writeBoolean(info->isCompressed());
+        rc += tightMarshalObjectArray1(wireFormat, info->getBrokerPath(), bs);
+        rc += tightMarshalLong1(wireFormat, info->getArrival(), bs);
+        rc += tightMarshalString1(info->getUserID(), bs);
+        bs->writeBoolean(info->isRecievedByDFBridge());
+        if (wireVersion >= 2) {
+            bs->writeBoolean(info->isDroppable());
         }
-        if( wireVersion >= 3 ) {
-            rc += tightMarshalObjectArray1( wireFormat, info->getCluster(), bs );
+        if (wireVersion >= 3) {
+            rc += tightMarshalObjectArray1(wireFormat, info->getCluster(), bs);
         }
-        if( wireVersion >= 3 ) {
-            rc += tightMarshalLong1( wireFormat, info->getBrokerInTime(), bs );
+        if (wireVersion >= 3) {
+            rc += tightMarshalLong1(wireFormat, info->getBrokerInTime(), bs);
         }
-        if( wireVersion >= 3 ) {
-            rc += tightMarshalLong1( wireFormat, info->getBrokerOutTime(), bs );
+        if (wireVersion >= 3) {
+            rc += tightMarshalLong1(wireFormat, info->getBrokerOutTime(), bs);
         }
 
         return rc + 9;
     }
-    AMQ_CATCH_RETHROW( decaf::io::IOException )
-    AMQ_CATCH_EXCEPTION_CONVERT( exceptions::ActiveMQException, decaf::io::IOException )
-    AMQ_CATCHALL_THROW( decaf::io::IOException )
+    AMQ_CATCH_RETHROW(decaf::io::IOException)
+    AMQ_CATCH_EXCEPTION_CONVERT(exceptions::ActiveMQException, decaf::io::IOException)
+    AMQ_CATCHALL_THROW(decaf::io::IOException)
 }
 
 ///////////////////////////////////////////////////////////////////////////////
-void MessageMarshaller::tightMarshal2( OpenWireFormat* wireFormat, DataStructure* dataStructure, DataOutputStream* dataOut, BooleanStream* bs ) {
+void MessageMarshaller::tightMarshal2(OpenWireFormat* wireFormat, DataStructure* dataStructure, DataOutputStream* dataOut, BooleanStream* bs) {
 
     try {
 
-        BaseCommandMarshaller::tightMarshal2( wireFormat, dataStructure, dataOut, bs );
+        BaseCommandMarshaller::tightMarshal2(wireFormat, dataStructure, dataOut, bs );
 
         Message* info =
-            dynamic_cast<Message*>( dataStructure );
+            dynamic_cast<Message*>(dataStructure);
 
         int wireVersion = wireFormat->getVersion();
 
-        tightMarshalCachedObject2( wireFormat, info->getProducerId().get(), dataOut, bs );
-        tightMarshalCachedObject2( wireFormat, info->getDestination().get(), dataOut, bs );
-        tightMarshalCachedObject2( wireFormat, info->getTransactionId().get(), dataOut, bs );
-        tightMarshalCachedObject2( wireFormat, info->getOriginalDestination().get(), dataOut, bs );
-        tightMarshalNestedObject2( wireFormat, info->getMessageId().get(), dataOut, bs );
-        tightMarshalCachedObject2( wireFormat, info->getOriginalTransactionId().get(), dataOut, bs );
-        tightMarshalString2( info->getGroupID(), dataOut, bs );
-        dataOut->writeInt( info->getGroupSequence() );
-        tightMarshalString2( info->getCorrelationId(), dataOut, bs );
+        tightMarshalCachedObject2(wireFormat, info->getProducerId().get(), dataOut, bs);
+        tightMarshalCachedObject2(wireFormat, info->getDestination().get(), dataOut, bs);
+        tightMarshalCachedObject2(wireFormat, info->getTransactionId().get(), dataOut, bs);
+        tightMarshalCachedObject2(wireFormat, info->getOriginalDestination().get(), dataOut, bs);
+        tightMarshalNestedObject2(wireFormat, info->getMessageId().get(), dataOut, bs);
+        tightMarshalCachedObject2(wireFormat, info->getOriginalTransactionId().get(), dataOut, bs);
+        tightMarshalString2(info->getGroupID(), dataOut, bs);
+        dataOut->writeInt(info->getGroupSequence());
+        tightMarshalString2(info->getCorrelationId(), dataOut, bs);
         bs->readBoolean();
-        tightMarshalLong2( wireFormat, info->getExpiration(), dataOut, bs );
-        dataOut->write( info->getPriority() );
-        tightMarshalNestedObject2( wireFormat, info->getReplyTo().get(), dataOut, bs );
-        tightMarshalLong2( wireFormat, info->getTimestamp(), dataOut, bs );
-        tightMarshalString2( info->getType(), dataOut, bs );
-        if( bs->readBoolean() ) {
-            dataOut->writeInt( (int)info->getContent().size() );
-            dataOut->write( (const unsigned char*)(&info->getContent()[0]), (int)info->getContent().size(), 0, (int)info->getContent().size() );
-        }
-        if( bs->readBoolean() ) {
-            dataOut->writeInt( (int)info->getMarshalledProperties().size() );
-            dataOut->write( (const unsigned char*)(&info->getMarshalledProperties()[0]), (int)info->getMarshalledProperties().size(), 0, (int)info->getMarshalledProperties().size() );
+        tightMarshalLong2(wireFormat, info->getExpiration(), dataOut, bs);
+        dataOut->write(info->getPriority());
+        tightMarshalNestedObject2(wireFormat, info->getReplyTo().get(), dataOut, bs);
+        tightMarshalLong2(wireFormat, info->getTimestamp(), dataOut, bs);
+        tightMarshalString2(info->getType(), dataOut, bs);
+        if (bs->readBoolean()) {
+            dataOut->writeInt((int)info->getContent().size() );
+            dataOut->write((const unsigned char*)(&info->getContent()[0]), (int)info->getContent().size(), 0, (int)info->getContent().size());
+        }
+        if (bs->readBoolean()) {
+            dataOut->writeInt((int)info->getMarshalledProperties().size() );
+            dataOut->write((const unsigned char*)(&info->getMarshalledProperties()[0]), (int)info->getMarshalledProperties().size(), 0, (int)info->getMarshalledProperties().size());
         }
-        tightMarshalNestedObject2( wireFormat, info->getDataStructure().get(), dataOut, bs );
-        tightMarshalCachedObject2( wireFormat, info->getTargetConsumerId().get(), dataOut, bs );
+        tightMarshalNestedObject2(wireFormat, info->getDataStructure().get(), dataOut, bs);
+        tightMarshalCachedObject2(wireFormat, info->getTargetConsumerId().get(), dataOut, bs);
         bs->readBoolean();
-        dataOut->writeInt( info->getRedeliveryCounter() );
-        tightMarshalObjectArray2( wireFormat, info->getBrokerPath(), dataOut, bs );
-        tightMarshalLong2( wireFormat, info->getArrival(), dataOut, bs );
-        tightMarshalString2( info->getUserID(), dataOut, bs );
+        dataOut->writeInt(info->getRedeliveryCounter());
+        tightMarshalObjectArray2(wireFormat, info->getBrokerPath(), dataOut, bs);
+        tightMarshalLong2(wireFormat, info->getArrival(), dataOut, bs);
+        tightMarshalString2(info->getUserID(), dataOut, bs);
         bs->readBoolean();
-        if( wireVersion >= 2 ) {
+        if (wireVersion >= 2) {
             bs->readBoolean();
         }
-        if( wireVersion >= 3 ) {
-            tightMarshalObjectArray2( wireFormat, info->getCluster(), dataOut, bs );
+        if (wireVersion >= 3) {
+            tightMarshalObjectArray2(wireFormat, info->getCluster(), dataOut, bs);
         }
-        if( wireVersion >= 3 ) {
-            tightMarshalLong2( wireFormat, info->getBrokerInTime(), dataOut, bs );
+        if (wireVersion >= 3) {
+            tightMarshalLong2(wireFormat, info->getBrokerInTime(), dataOut, bs);
         }
-        if( wireVersion >= 3 ) {
-            tightMarshalLong2( wireFormat, info->getBrokerOutTime(), dataOut, bs );
+        if (wireVersion >= 3) {
+            tightMarshalLong2(wireFormat, info->getBrokerOutTime(), dataOut, bs);
         }
     }
-    AMQ_CATCH_RETHROW( decaf::io::IOException )
-    AMQ_CATCH_EXCEPTION_CONVERT( exceptions::ActiveMQException, decaf::io::IOException )
-    AMQ_CATCHALL_THROW( decaf::io::IOException )
+    AMQ_CATCH_RETHROW(decaf::io::IOException)
+    AMQ_CATCH_EXCEPTION_CONVERT( exceptions::ActiveMQException, decaf::io::IOException)
+    AMQ_CATCHALL_THROW(decaf::io::IOException)
 }
 
 ///////////////////////////////////////////////////////////////////////////////
-void MessageMarshaller::looseUnmarshal( OpenWireFormat* wireFormat, DataStructure* dataStructure, DataInputStream* dataIn ) {
+void MessageMarshaller::looseUnmarshal(OpenWireFormat* wireFormat, DataStructure* dataStructure, DataInputStream* dataIn) {
 
     try {
 
-        BaseCommandMarshaller::looseUnmarshal( wireFormat, dataStructure, dataIn );
+        BaseCommandMarshaller::looseUnmarshal(wireFormat, dataStructure, dataIn);
         Message* info =
-            dynamic_cast<Message*>( dataStructure );
+            dynamic_cast<Message*>(dataStructure);
 
         int wireVersion = wireFormat->getVersion();
 
-        info->setProducerId( Pointer<ProducerId>( dynamic_cast< ProducerId* >( 
-            looseUnmarshalCachedObject( wireFormat, dataIn ) ) ) );
-        info->setDestination( Pointer<ActiveMQDestination>( dynamic_cast< ActiveMQDestination* >( 
-            looseUnmarshalCachedObject( wireFormat, dataIn ) ) ) );
-        info->setTransactionId( Pointer<TransactionId>( dynamic_cast< TransactionId* >( 
-            looseUnmarshalCachedObject( wireFormat, dataIn ) ) ) );
-        info->setOriginalDestination( Pointer<ActiveMQDestination>( dynamic_cast< ActiveMQDestination* >( 
-            looseUnmarshalCachedObject( wireFormat, dataIn ) ) ) );
-        info->setMessageId( Pointer<MessageId>( dynamic_cast< MessageId* >( 
-            looseUnmarshalNestedObject( wireFormat, dataIn ) ) ) );
-        info->setOriginalTransactionId( Pointer<TransactionId>( dynamic_cast< TransactionId* >( 
-            looseUnmarshalCachedObject( wireFormat, dataIn ) ) ) );
-        info->setGroupID( looseUnmarshalString( dataIn ) );
-        info->setGroupSequence( dataIn->readInt() );
-        info->setCorrelationId( looseUnmarshalString( dataIn ) );
-        info->setPersistent( dataIn->readBoolean() );
-        info->setExpiration( looseUnmarshalLong( wireFormat, dataIn ) );
-        info->setPriority( dataIn->readByte() );
-        info->setReplyTo( Pointer<ActiveMQDestination>( dynamic_cast< ActiveMQDestination* >( 
-            looseUnmarshalNestedObject( wireFormat, dataIn ) ) ) );
-        info->setTimestamp( looseUnmarshalLong( wireFormat, dataIn ) );
-        info->setType( looseUnmarshalString( dataIn ) );
-        info->setContent( looseUnmarshalByteArray( dataIn ) );
-        info->setMarshalledProperties( looseUnmarshalByteArray( dataIn ) );
-        info->setDataStructure( Pointer<DataStructure>( dynamic_cast< DataStructure* >( 
-            looseUnmarshalNestedObject( wireFormat, dataIn ) ) ) );
-        info->setTargetConsumerId( Pointer<ConsumerId>( dynamic_cast< ConsumerId* >( 
-            looseUnmarshalCachedObject( wireFormat, dataIn ) ) ) );
-        info->setCompressed( dataIn->readBoolean() );
-        info->setRedeliveryCounter( dataIn->readInt() );
+        info->setProducerId(Pointer<ProducerId>(dynamic_cast<ProducerId*>(
+            looseUnmarshalCachedObject(wireFormat, dataIn))));
+        info->setDestination(Pointer<ActiveMQDestination>(dynamic_cast<ActiveMQDestination*>(
+            looseUnmarshalCachedObject(wireFormat, dataIn))));
+        info->setTransactionId(Pointer<TransactionId>(dynamic_cast<TransactionId*>(
+            looseUnmarshalCachedObject(wireFormat, dataIn))));
+        info->setOriginalDestination(Pointer<ActiveMQDestination>(dynamic_cast<ActiveMQDestination*>(
+            looseUnmarshalCachedObject(wireFormat, dataIn))));
+        info->setMessageId(Pointer<MessageId>(dynamic_cast<MessageId*>(
+            looseUnmarshalNestedObject(wireFormat, dataIn))));
+        info->setOriginalTransactionId(Pointer<TransactionId>(dynamic_cast<TransactionId*>(
+            looseUnmarshalCachedObject(wireFormat, dataIn))));
+        info->setGroupID(looseUnmarshalString(dataIn));
+        info->setGroupSequence(dataIn->readInt());
+        info->setCorrelationId(looseUnmarshalString(dataIn));
+        info->setPersistent(dataIn->readBoolean());
+        info->setExpiration(looseUnmarshalLong(wireFormat, dataIn));
+        info->setPriority(dataIn->readByte());
+        info->setReplyTo(Pointer<ActiveMQDestination>(dynamic_cast<ActiveMQDestination*>(
+            looseUnmarshalNestedObject(wireFormat, dataIn))));
+        info->setTimestamp(looseUnmarshalLong(wireFormat, dataIn));
+        info->setType(looseUnmarshalString(dataIn));
+        info->setContent(looseUnmarshalByteArray(dataIn));
+        info->setMarshalledProperties(looseUnmarshalByteArray(dataIn));
+        info->setDataStructure(Pointer<DataStructure>(dynamic_cast<DataStructure*>(
+            looseUnmarshalNestedObject(wireFormat, dataIn))));
+        info->setTargetConsumerId(Pointer<ConsumerId>(dynamic_cast<ConsumerId*>(
+            looseUnmarshalCachedObject(wireFormat, dataIn))));
+        info->setCompressed(dataIn->readBoolean());
+        info->setRedeliveryCounter(dataIn->readInt());
 
-        if( dataIn->readBoolean() ) {
+        if (dataIn->readBoolean()) {
             short size = dataIn->readShort();
-            info->getBrokerPath().reserve( size );
-            for( int i = 0; i < size; i++ ) {
-                info->getBrokerPath().push_back( Pointer<BrokerId>( dynamic_cast<BrokerId* >(
-                    looseUnmarshalNestedObject( wireFormat, dataIn ) ) ) );
+            info->getBrokerPath().reserve(size);
+            for (int i = 0; i < size; i++) {
+                info->getBrokerPath().push_back( Pointer<BrokerId>(dynamic_cast<BrokerId*>(
+                    looseUnmarshalNestedObject(wireFormat, dataIn))));
             }
         } else {
             info->getBrokerPath().clear();
         }
-        info->setArrival( looseUnmarshalLong( wireFormat, dataIn ) );
-        info->setUserID( looseUnmarshalString( dataIn ) );
-        info->setRecievedByDFBridge( dataIn->readBoolean() );
-        if( wireVersion >= 2 ) {
-            info->setDroppable( dataIn->readBoolean() );
+        info->setArrival(looseUnmarshalLong(wireFormat, dataIn));
+        info->setUserID(looseUnmarshalString(dataIn));
+        info->setRecievedByDFBridge(dataIn->readBoolean());
+        if (wireVersion >= 2) {
+            info->setDroppable(dataIn->readBoolean());
         }
-        if( wireVersion >= 3 ) {
+        if (wireVersion >= 3) {
 
-            if( dataIn->readBoolean() ) {
+            if (dataIn->readBoolean()) {
                 short size = dataIn->readShort();
-                info->getCluster().reserve( size );
-                for( int i = 0; i < size; i++ ) {
-                    info->getCluster().push_back( Pointer<BrokerId>( dynamic_cast<BrokerId* >(
-                        looseUnmarshalNestedObject( wireFormat, dataIn ) ) ) );
+                info->getCluster().reserve(size);
+                for (int i = 0; i < size; i++) {
+                    info->getCluster().push_back( Pointer<BrokerId>(dynamic_cast<BrokerId*>(
+                        looseUnmarshalNestedObject(wireFormat, dataIn))));
                 }
             } else {
                 info->getCluster().clear();
             }
         }
-        if( wireVersion >= 3 ) {
-            info->setBrokerInTime( looseUnmarshalLong( wireFormat, dataIn ) );
+        if (wireVersion >= 3) {
+            info->setBrokerInTime(looseUnmarshalLong(wireFormat, dataIn));
         }
-        if( wireVersion >= 3 ) {
-            info->setBrokerOutTime( looseUnmarshalLong( wireFormat, dataIn ) );
+        if (wireVersion >= 3) {
+            info->setBrokerOutTime(looseUnmarshalLong(wireFormat, dataIn));
         }
     }
-    AMQ_CATCH_RETHROW( decaf::io::IOException )
-    AMQ_CATCH_EXCEPTION_CONVERT( exceptions::ActiveMQException, decaf::io::IOException )
-    AMQ_CATCHALL_THROW( decaf::io::IOException )
+    AMQ_CATCH_RETHROW(decaf::io::IOException)
+    AMQ_CATCH_EXCEPTION_CONVERT(exceptions::ActiveMQException, decaf::io::IOException)
+    AMQ_CATCHALL_THROW(decaf::io::IOException)
 }
 
 ///////////////////////////////////////////////////////////////////////////////
-void MessageMarshaller::looseMarshal( OpenWireFormat* wireFormat, DataStructure* dataStructure, DataOutputStream* dataOut ) {
+void MessageMarshaller::looseMarshal(OpenWireFormat* wireFormat, DataStructure* dataStructure, DataOutputStream* dataOut) {
 
     try {
 
         Message* info =
-            dynamic_cast<Message*>( dataStructure );
-        BaseCommandMarshaller::looseMarshal( wireFormat, dataStructure, dataOut );
+            dynamic_cast<Message*>(dataStructure);
+        BaseCommandMarshaller::looseMarshal(wireFormat, dataStructure, dataOut);
 
         int wireVersion = wireFormat->getVersion();
 
-        looseMarshalCachedObject( wireFormat, info->getProducerId().get(), dataOut );
-        looseMarshalCachedObject( wireFormat, info->getDestination().get(), dataOut );
-        looseMarshalCachedObject( wireFormat, info->getTransactionId().get(), dataOut );
-        looseMarshalCachedObject( wireFormat, info->getOriginalDestination().get(), dataOut );
-        looseMarshalNestedObject( wireFormat, info->getMessageId().get(), dataOut );
-        looseMarshalCachedObject( wireFormat, info->getOriginalTransactionId().get(), dataOut );
-        looseMarshalString( info->getGroupID(), dataOut );
-        dataOut->writeInt( info->getGroupSequence() );
-        looseMarshalString( info->getCorrelationId(), dataOut );
-        dataOut->writeBoolean( info->isPersistent() );
-        looseMarshalLong( wireFormat, info->getExpiration(), dataOut );
-        dataOut->write( info->getPriority() );
-        looseMarshalNestedObject( wireFormat, info->getReplyTo().get(), dataOut );
-        looseMarshalLong( wireFormat, info->getTimestamp(), dataOut );
-        looseMarshalString( info->getType(), dataOut );
+        looseMarshalCachedObject(wireFormat, info->getProducerId().get(), dataOut);
+        looseMarshalCachedObject(wireFormat, info->getDestination().get(), dataOut);
+        looseMarshalCachedObject(wireFormat, info->getTransactionId().get(), dataOut);
+        looseMarshalCachedObject(wireFormat, info->getOriginalDestination().get(), dataOut);
+        looseMarshalNestedObject(wireFormat, info->getMessageId().get(), dataOut);
+        looseMarshalCachedObject(wireFormat, info->getOriginalTransactionId().get(), dataOut);
+        looseMarshalString(info->getGroupID(), dataOut);
+        dataOut->writeInt(info->getGroupSequence());
+        looseMarshalString(info->getCorrelationId(), dataOut);
+        dataOut->writeBoolean(info->isPersistent());
+        looseMarshalLong(wireFormat, info->getExpiration(), dataOut);
+        dataOut->write(info->getPriority());
+        looseMarshalNestedObject(wireFormat, info->getReplyTo().get(), dataOut);
+        looseMarshalLong(wireFormat, info->getTimestamp(), dataOut);
+        looseMarshalString(info->getType(), dataOut);
         dataOut->write( info->getContent().size() != 0 );
         if( info->getContent().size() != 0 ) {
             dataOut->writeInt( (int)info->getContent().size() );
-            dataOut->write( (const unsigned char*)(&info->getContent()[0]), (int)info->getContent().size(), 0, (int)info->getContent().size() );
+            dataOut->write((const unsigned char*)(&info->getContent()[0]), (int)info->getContent().size(), 0, (int)info->getContent().size());
         }
         dataOut->write( info->getMarshalledProperties().size() != 0 );
         if( info->getMarshalledProperties().size() != 0 ) {
             dataOut->writeInt( (int)info->getMarshalledProperties().size() );
-            dataOut->write( (const unsigned char*)(&info->getMarshalledProperties()[0]), (int)info->getMarshalledProperties().size(), 0, (int)info->getMarshalledProperties().size() );
+            dataOut->write((const unsigned char*)(&info->getMarshalledProperties()[0]), (int)info->getMarshalledProperties().size(), 0, (int)info->getMarshalledProperties().size());
         }
-        looseMarshalNestedObject( wireFormat, info->getDataStructure().get(), dataOut );
-        looseMarshalCachedObject( wireFormat, info->getTargetConsumerId().get(), dataOut );
-        dataOut->writeBoolean( info->isCompressed() );
-        dataOut->writeInt( info->getRedeliveryCounter() );
-        looseMarshalObjectArray( wireFormat, info->getBrokerPath(), dataOut );
-        looseMarshalLong( wireFormat, info->getArrival(), dataOut );
-        looseMarshalString( info->getUserID(), dataOut );
-        dataOut->writeBoolean( info->isRecievedByDFBridge() );
-        if( wireVersion >= 2 ) {
-            dataOut->writeBoolean( info->isDroppable() );
+        looseMarshalNestedObject(wireFormat, info->getDataStructure().get(), dataOut);
+        looseMarshalCachedObject(wireFormat, info->getTargetConsumerId().get(), dataOut);
+        dataOut->writeBoolean(info->isCompressed());
+        dataOut->writeInt(info->getRedeliveryCounter());
+        looseMarshalObjectArray(wireFormat, info->getBrokerPath(), dataOut);
+        looseMarshalLong(wireFormat, info->getArrival(), dataOut);
+        looseMarshalString(info->getUserID(), dataOut);
+        dataOut->writeBoolean(info->isRecievedByDFBridge());
+        if (wireVersion >= 2) {
+            dataOut->writeBoolean(info->isDroppable());
         }
-        if( wireVersion >= 3 ) {
-            looseMarshalObjectArray( wireFormat, info->getCluster(), dataOut );
+        if (wireVersion >= 3) {
+            looseMarshalObjectArray(wireFormat, info->getCluster(), dataOut);
         }
-        if( wireVersion >= 3 ) {
-            looseMarshalLong( wireFormat, info->getBrokerInTime(), dataOut );
+        if (wireVersion >= 3) {
+            looseMarshalLong(wireFormat, info->getBrokerInTime(), dataOut);
         }
-        if( wireVersion >= 3 ) {
-            looseMarshalLong( wireFormat, info->getBrokerOutTime(), dataOut );
+        if (wireVersion >= 3) {
+            looseMarshalLong(wireFormat, info->getBrokerOutTime(), dataOut);
         }
     }
-    AMQ_CATCH_RETHROW( decaf::io::IOException )
-    AMQ_CATCH_EXCEPTION_CONVERT( exceptions::ActiveMQException, decaf::io::IOException )
-    AMQ_CATCHALL_THROW( decaf::io::IOException )
+    AMQ_CATCH_RETHROW(decaf::io::IOException)
+    AMQ_CATCH_EXCEPTION_CONVERT(exceptions::ActiveMQException, decaf::io::IOException)
+    AMQ_CATCHALL_THROW(decaf::io::IOException)
 }
 

Modified: activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/wireformat/openwire/marshal/generated/MessageMarshaller.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/wireformat/openwire/marshal/generated/MessageMarshaller.h?rev=1460467&r1=1460466&r2=1460467&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/wireformat/openwire/marshal/generated/MessageMarshaller.h (original)
+++ activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/wireformat/openwire/marshal/generated/MessageMarshaller.h Sun Mar 24 21:30:52 2013
@@ -33,11 +33,11 @@
 #include <activemq/wireformat/openwire/OpenWireFormat.h>
 #include <activemq/wireformat/openwire/utils/BooleanStream.h>
 
-namespace activemq{
-namespace wireformat{
-namespace openwire{
-namespace marshal{
-namespace generated{
+namespace activemq {
+namespace wireformat {
+namespace openwire {
+namespace marshal {
+namespace generated {
 
     /**
      * Marshaling code for Open Wire Format for MessageMarshaller
@@ -52,27 +52,27 @@ namespace generated{
         MessageMarshaller() {}
         virtual ~MessageMarshaller() {}
 
-        virtual void tightUnmarshal( OpenWireFormat* wireFormat,
-                                     commands::DataStructure* dataStructure,
-                                     decaf::io::DataInputStream* dataIn,
-                                     utils::BooleanStream* bs );
+        virtual void tightUnmarshal(OpenWireFormat* wireFormat,
+                                    commands::DataStructure* dataStructure,
+                                    decaf::io::DataInputStream* dataIn,
+                                    utils::BooleanStream* bs);
+
+        virtual int tightMarshal1(OpenWireFormat* wireFormat,
+                                  commands::DataStructure* dataStructure,
+                                  utils::BooleanStream* bs);
 
-        virtual int tightMarshal1( OpenWireFormat* wireFormat,
+        virtual void tightMarshal2(OpenWireFormat* wireFormat,
                                    commands::DataStructure* dataStructure,
-                                   utils::BooleanStream* bs );
+                                   decaf::io::DataOutputStream* dataOut,
+                                   utils::BooleanStream* bs);
 
-        virtual void tightMarshal2( OpenWireFormat* wireFormat,
+        virtual void looseUnmarshal(OpenWireFormat* wireFormat,
                                     commands::DataStructure* dataStructure,
-                                    decaf::io::DataOutputStream* dataOut,
-                                    utils::BooleanStream* bs );
+                                    decaf::io::DataInputStream* dataIn);
 
-        virtual void looseUnmarshal( OpenWireFormat* wireFormat,
-                                     commands::DataStructure* dataStructure,
-                                     decaf::io::DataInputStream* dataIn );
-
-        virtual void looseMarshal( OpenWireFormat* wireFormat,
-                                   commands::DataStructure* dataStructure,
-                                   decaf::io::DataOutputStream* dataOut );
+        virtual void looseMarshal(OpenWireFormat* wireFormat,
+                                  commands::DataStructure* dataStructure,
+                                  decaf::io::DataOutputStream* dataOut);
 
     };
 

Modified: activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/wireformat/openwire/marshal/generated/MessagePullMarshaller.cpp
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/wireformat/openwire/marshal/generated/MessagePullMarshaller.cpp?rev=1460467&r1=1460466&r2=1460467&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/wireformat/openwire/marshal/generated/MessagePullMarshaller.cpp (original)
+++ activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/wireformat/openwire/marshal/generated/MessagePullMarshaller.cpp Sun Mar 24 21:30:52 2013
@@ -51,143 +51,143 @@ unsigned char MessagePullMarshaller::get
 }
 
 ///////////////////////////////////////////////////////////////////////////////
-void MessagePullMarshaller::tightUnmarshal( OpenWireFormat* wireFormat, DataStructure* dataStructure, DataInputStream* dataIn, BooleanStream* bs ) {
+void MessagePullMarshaller::tightUnmarshal(OpenWireFormat* wireFormat, DataStructure* dataStructure, DataInputStream* dataIn, BooleanStream* bs) {
 
     try {
 
-        BaseCommandMarshaller::tightUnmarshal( wireFormat, dataStructure, dataIn, bs );
+        BaseCommandMarshaller::tightUnmarshal(wireFormat, dataStructure, dataIn, bs);
 
         MessagePull* info =
-            dynamic_cast<MessagePull*>( dataStructure );
+            dynamic_cast<MessagePull*>(dataStructure);
 
         int wireVersion = wireFormat->getVersion();
 
-        info->setConsumerId( Pointer<ConsumerId>( dynamic_cast< ConsumerId* >(
-            tightUnmarshalCachedObject( wireFormat, dataIn, bs ) ) ) );
-        info->setDestination( Pointer<ActiveMQDestination>( dynamic_cast< ActiveMQDestination* >(
-            tightUnmarshalCachedObject( wireFormat, dataIn, bs ) ) ) );
-        info->setTimeout( tightUnmarshalLong( wireFormat, dataIn, bs ) );
-        if( wireVersion >= 3 ) {
-            info->setCorrelationId( tightUnmarshalString( dataIn, bs ) );
-        }
-        if( wireVersion >= 3 ) {
-            info->setMessageId( Pointer<MessageId>( dynamic_cast< MessageId* >(
-                tightUnmarshalNestedObject( wireFormat, dataIn, bs ) ) ) );
+        info->setConsumerId(Pointer<ConsumerId>(dynamic_cast<ConsumerId* >(
+            tightUnmarshalCachedObject(wireFormat, dataIn, bs))));
+        info->setDestination(Pointer<ActiveMQDestination>(dynamic_cast<ActiveMQDestination* >(
+            tightUnmarshalCachedObject(wireFormat, dataIn, bs))));
+        info->setTimeout(tightUnmarshalLong(wireFormat, dataIn, bs));
+        if (wireVersion >= 3) {
+            info->setCorrelationId(tightUnmarshalString(dataIn, bs));
+        }
+        if (wireVersion >= 3) {
+            info->setMessageId(Pointer<MessageId>(dynamic_cast<MessageId* >(
+                tightUnmarshalNestedObject(wireFormat, dataIn, bs))));
         }
     }
-    AMQ_CATCH_RETHROW( decaf::io::IOException )
-    AMQ_CATCH_EXCEPTION_CONVERT( exceptions::ActiveMQException, decaf::io::IOException )
-    AMQ_CATCHALL_THROW( decaf::io::IOException )
+    AMQ_CATCH_RETHROW(decaf::io::IOException)
+    AMQ_CATCH_EXCEPTION_CONVERT(exceptions::ActiveMQException, decaf::io::IOException)
+    AMQ_CATCHALL_THROW(decaf::io::IOException)
 }
 
 ///////////////////////////////////////////////////////////////////////////////
-int MessagePullMarshaller::tightMarshal1( OpenWireFormat* wireFormat, DataStructure* dataStructure, BooleanStream* bs ) {
+int MessagePullMarshaller::tightMarshal1(OpenWireFormat* wireFormat, DataStructure* dataStructure, BooleanStream* bs) {
 
     try {
 
         MessagePull* info =
-            dynamic_cast<MessagePull*>( dataStructure );
+            dynamic_cast<MessagePull*>(dataStructure);
 
-        int rc = BaseCommandMarshaller::tightMarshal1( wireFormat, dataStructure, bs );
+        int rc = BaseCommandMarshaller::tightMarshal1(wireFormat, dataStructure, bs);
 
         int wireVersion = wireFormat->getVersion();
 
-        rc += tightMarshalCachedObject1( wireFormat, info->getConsumerId().get(), bs );
-        rc += tightMarshalCachedObject1( wireFormat, info->getDestination().get(), bs );
-        rc += tightMarshalLong1( wireFormat, info->getTimeout(), bs );
-        if( wireVersion >= 3 ) {
-            rc += tightMarshalString1( info->getCorrelationId(), bs );
+        rc += tightMarshalCachedObject1(wireFormat, info->getConsumerId().get(), bs);
+        rc += tightMarshalCachedObject1(wireFormat, info->getDestination().get(), bs);
+        rc += tightMarshalLong1(wireFormat, info->getTimeout(), bs);
+        if (wireVersion >= 3) {
+            rc += tightMarshalString1(info->getCorrelationId(), bs);
         }
-        if( wireVersion >= 3 ) {
-            rc += tightMarshalNestedObject1( wireFormat, info->getMessageId().get(), bs );
+        if (wireVersion >= 3) {
+            rc += tightMarshalNestedObject1(wireFormat, info->getMessageId().get(), bs);
         }
 
         return rc + 0;
     }
-    AMQ_CATCH_RETHROW( decaf::io::IOException )
-    AMQ_CATCH_EXCEPTION_CONVERT( exceptions::ActiveMQException, decaf::io::IOException )
-    AMQ_CATCHALL_THROW( decaf::io::IOException )
+    AMQ_CATCH_RETHROW(decaf::io::IOException)
+    AMQ_CATCH_EXCEPTION_CONVERT(exceptions::ActiveMQException, decaf::io::IOException)
+    AMQ_CATCHALL_THROW(decaf::io::IOException)
 }
 
 ///////////////////////////////////////////////////////////////////////////////
-void MessagePullMarshaller::tightMarshal2( OpenWireFormat* wireFormat, DataStructure* dataStructure, DataOutputStream* dataOut, BooleanStream* bs ) {
+void MessagePullMarshaller::tightMarshal2(OpenWireFormat* wireFormat, DataStructure* dataStructure, DataOutputStream* dataOut, BooleanStream* bs) {
 
     try {
 
-        BaseCommandMarshaller::tightMarshal2( wireFormat, dataStructure, dataOut, bs );
+        BaseCommandMarshaller::tightMarshal2(wireFormat, dataStructure, dataOut, bs );
 
         MessagePull* info =
-            dynamic_cast<MessagePull*>( dataStructure );
+            dynamic_cast<MessagePull*>(dataStructure);
 
         int wireVersion = wireFormat->getVersion();
 
-        tightMarshalCachedObject2( wireFormat, info->getConsumerId().get(), dataOut, bs );
-        tightMarshalCachedObject2( wireFormat, info->getDestination().get(), dataOut, bs );
-        tightMarshalLong2( wireFormat, info->getTimeout(), dataOut, bs );
-        if( wireVersion >= 3 ) {
-            tightMarshalString2( info->getCorrelationId(), dataOut, bs );
+        tightMarshalCachedObject2(wireFormat, info->getConsumerId().get(), dataOut, bs);
+        tightMarshalCachedObject2(wireFormat, info->getDestination().get(), dataOut, bs);
+        tightMarshalLong2(wireFormat, info->getTimeout(), dataOut, bs);
+        if (wireVersion >= 3) {
+            tightMarshalString2(info->getCorrelationId(), dataOut, bs);
         }
-        if( wireVersion >= 3 ) {
-            tightMarshalNestedObject2( wireFormat, info->getMessageId().get(), dataOut, bs );
+        if (wireVersion >= 3) {
+            tightMarshalNestedObject2(wireFormat, info->getMessageId().get(), dataOut, bs);
         }
     }
-    AMQ_CATCH_RETHROW( decaf::io::IOException )
-    AMQ_CATCH_EXCEPTION_CONVERT( exceptions::ActiveMQException, decaf::io::IOException )
-    AMQ_CATCHALL_THROW( decaf::io::IOException )
+    AMQ_CATCH_RETHROW(decaf::io::IOException)
+    AMQ_CATCH_EXCEPTION_CONVERT( exceptions::ActiveMQException, decaf::io::IOException)
+    AMQ_CATCHALL_THROW(decaf::io::IOException)
 }
 
 ///////////////////////////////////////////////////////////////////////////////
-void MessagePullMarshaller::looseUnmarshal( OpenWireFormat* wireFormat, DataStructure* dataStructure, DataInputStream* dataIn ) {
+void MessagePullMarshaller::looseUnmarshal(OpenWireFormat* wireFormat, DataStructure* dataStructure, DataInputStream* dataIn) {
 
     try {
 
-        BaseCommandMarshaller::looseUnmarshal( wireFormat, dataStructure, dataIn );
+        BaseCommandMarshaller::looseUnmarshal(wireFormat, dataStructure, dataIn);
         MessagePull* info =
-            dynamic_cast<MessagePull*>( dataStructure );
+            dynamic_cast<MessagePull*>(dataStructure);
 
         int wireVersion = wireFormat->getVersion();
 
-        info->setConsumerId( Pointer<ConsumerId>( dynamic_cast< ConsumerId* >( 
-            looseUnmarshalCachedObject( wireFormat, dataIn ) ) ) );
-        info->setDestination( Pointer<ActiveMQDestination>( dynamic_cast< ActiveMQDestination* >( 
-            looseUnmarshalCachedObject( wireFormat, dataIn ) ) ) );
-        info->setTimeout( looseUnmarshalLong( wireFormat, dataIn ) );
-        if( wireVersion >= 3 ) {
-            info->setCorrelationId( looseUnmarshalString( dataIn ) );
-        }
-        if( wireVersion >= 3 ) {
-            info->setMessageId( Pointer<MessageId>( dynamic_cast< MessageId* >( 
-                looseUnmarshalNestedObject( wireFormat, dataIn ) ) ) );
+        info->setConsumerId(Pointer<ConsumerId>(dynamic_cast<ConsumerId*>(
+            looseUnmarshalCachedObject(wireFormat, dataIn))));
+        info->setDestination(Pointer<ActiveMQDestination>(dynamic_cast<ActiveMQDestination*>(
+            looseUnmarshalCachedObject(wireFormat, dataIn))));
+        info->setTimeout(looseUnmarshalLong(wireFormat, dataIn));
+        if (wireVersion >= 3) {
+            info->setCorrelationId(looseUnmarshalString(dataIn));
+        }
+        if (wireVersion >= 3) {
+            info->setMessageId(Pointer<MessageId>(dynamic_cast<MessageId*>(
+                looseUnmarshalNestedObject(wireFormat, dataIn))));
         }
     }
-    AMQ_CATCH_RETHROW( decaf::io::IOException )
-    AMQ_CATCH_EXCEPTION_CONVERT( exceptions::ActiveMQException, decaf::io::IOException )
-    AMQ_CATCHALL_THROW( decaf::io::IOException )
+    AMQ_CATCH_RETHROW(decaf::io::IOException)
+    AMQ_CATCH_EXCEPTION_CONVERT(exceptions::ActiveMQException, decaf::io::IOException)
+    AMQ_CATCHALL_THROW(decaf::io::IOException)
 }
 
 ///////////////////////////////////////////////////////////////////////////////
-void MessagePullMarshaller::looseMarshal( OpenWireFormat* wireFormat, DataStructure* dataStructure, DataOutputStream* dataOut ) {
+void MessagePullMarshaller::looseMarshal(OpenWireFormat* wireFormat, DataStructure* dataStructure, DataOutputStream* dataOut) {
 
     try {
 
         MessagePull* info =
-            dynamic_cast<MessagePull*>( dataStructure );
-        BaseCommandMarshaller::looseMarshal( wireFormat, dataStructure, dataOut );
+            dynamic_cast<MessagePull*>(dataStructure);
+        BaseCommandMarshaller::looseMarshal(wireFormat, dataStructure, dataOut);
 
         int wireVersion = wireFormat->getVersion();
 
-        looseMarshalCachedObject( wireFormat, info->getConsumerId().get(), dataOut );
-        looseMarshalCachedObject( wireFormat, info->getDestination().get(), dataOut );
-        looseMarshalLong( wireFormat, info->getTimeout(), dataOut );
-        if( wireVersion >= 3 ) {
-            looseMarshalString( info->getCorrelationId(), dataOut );
+        looseMarshalCachedObject(wireFormat, info->getConsumerId().get(), dataOut);
+        looseMarshalCachedObject(wireFormat, info->getDestination().get(), dataOut);
+        looseMarshalLong(wireFormat, info->getTimeout(), dataOut);
+        if (wireVersion >= 3) {
+            looseMarshalString(info->getCorrelationId(), dataOut);
         }
-        if( wireVersion >= 3 ) {
-            looseMarshalNestedObject( wireFormat, info->getMessageId().get(), dataOut );
+        if (wireVersion >= 3) {
+            looseMarshalNestedObject(wireFormat, info->getMessageId().get(), dataOut);
         }
     }
-    AMQ_CATCH_RETHROW( decaf::io::IOException )
-    AMQ_CATCH_EXCEPTION_CONVERT( exceptions::ActiveMQException, decaf::io::IOException )
-    AMQ_CATCHALL_THROW( decaf::io::IOException )
+    AMQ_CATCH_RETHROW(decaf::io::IOException)
+    AMQ_CATCH_EXCEPTION_CONVERT(exceptions::ActiveMQException, decaf::io::IOException)
+    AMQ_CATCHALL_THROW(decaf::io::IOException)
 }
 

Modified: activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/wireformat/openwire/marshal/generated/MessagePullMarshaller.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/wireformat/openwire/marshal/generated/MessagePullMarshaller.h?rev=1460467&r1=1460466&r2=1460467&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/wireformat/openwire/marshal/generated/MessagePullMarshaller.h (original)
+++ activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/wireformat/openwire/marshal/generated/MessagePullMarshaller.h Sun Mar 24 21:30:52 2013
@@ -33,11 +33,11 @@
 #include <activemq/wireformat/openwire/OpenWireFormat.h>
 #include <activemq/wireformat/openwire/utils/BooleanStream.h>
 
-namespace activemq{
-namespace wireformat{
-namespace openwire{
-namespace marshal{
-namespace generated{
+namespace activemq {
+namespace wireformat {
+namespace openwire {
+namespace marshal {
+namespace generated {
 
     /**
      * Marshaling code for Open Wire Format for MessagePullMarshaller
@@ -56,27 +56,27 @@ namespace generated{
 
         virtual unsigned char getDataStructureType() const;
 
-        virtual void tightUnmarshal( OpenWireFormat* wireFormat,
-                                     commands::DataStructure* dataStructure,
-                                     decaf::io::DataInputStream* dataIn,
-                                     utils::BooleanStream* bs );
+        virtual void tightUnmarshal(OpenWireFormat* wireFormat,
+                                    commands::DataStructure* dataStructure,
+                                    decaf::io::DataInputStream* dataIn,
+                                    utils::BooleanStream* bs);
+
+        virtual int tightMarshal1(OpenWireFormat* wireFormat,
+                                  commands::DataStructure* dataStructure,
+                                  utils::BooleanStream* bs);
 
-        virtual int tightMarshal1( OpenWireFormat* wireFormat,
+        virtual void tightMarshal2(OpenWireFormat* wireFormat,
                                    commands::DataStructure* dataStructure,
-                                   utils::BooleanStream* bs );
+                                   decaf::io::DataOutputStream* dataOut,
+                                   utils::BooleanStream* bs);
 
-        virtual void tightMarshal2( OpenWireFormat* wireFormat,
+        virtual void looseUnmarshal(OpenWireFormat* wireFormat,
                                     commands::DataStructure* dataStructure,
-                                    decaf::io::DataOutputStream* dataOut,
-                                    utils::BooleanStream* bs );
+                                    decaf::io::DataInputStream* dataIn);
 
-        virtual void looseUnmarshal( OpenWireFormat* wireFormat,
-                                     commands::DataStructure* dataStructure,
-                                     decaf::io::DataInputStream* dataIn );
-
-        virtual void looseMarshal( OpenWireFormat* wireFormat,
-                                   commands::DataStructure* dataStructure,
-                                   decaf::io::DataOutputStream* dataOut );
+        virtual void looseMarshal(OpenWireFormat* wireFormat,
+                                  commands::DataStructure* dataStructure,
+                                  decaf::io::DataOutputStream* dataOut);
 
     };
 

Modified: activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/wireformat/openwire/marshal/generated/NetworkBridgeFilterMarshaller.cpp
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/wireformat/openwire/marshal/generated/NetworkBridgeFilterMarshaller.cpp?rev=1460467&r1=1460466&r2=1460467&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/wireformat/openwire/marshal/generated/NetworkBridgeFilterMarshaller.cpp (original)
+++ activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/wireformat/openwire/marshal/generated/NetworkBridgeFilterMarshaller.cpp Sun Mar 24 21:30:52 2013
@@ -51,88 +51,88 @@ unsigned char NetworkBridgeFilterMarshal
 }
 
 ///////////////////////////////////////////////////////////////////////////////
-void NetworkBridgeFilterMarshaller::tightUnmarshal( OpenWireFormat* wireFormat, DataStructure* dataStructure, DataInputStream* dataIn, BooleanStream* bs ) {
+void NetworkBridgeFilterMarshaller::tightUnmarshal(OpenWireFormat* wireFormat, DataStructure* dataStructure, DataInputStream* dataIn, BooleanStream* bs) {
 
     try {
 
-        BaseDataStreamMarshaller::tightUnmarshal( wireFormat, dataStructure, dataIn, bs );
+        BaseDataStreamMarshaller::tightUnmarshal(wireFormat, dataStructure, dataIn, bs);
 
         NetworkBridgeFilter* info =
-            dynamic_cast<NetworkBridgeFilter*>( dataStructure );
-        info->setNetworkTTL( dataIn->readInt() );
-        info->setNetworkBrokerId( Pointer<BrokerId>( dynamic_cast< BrokerId* >(
-            tightUnmarshalCachedObject( wireFormat, dataIn, bs ) ) ) );
+            dynamic_cast<NetworkBridgeFilter*>(dataStructure);
+        info->setNetworkTTL(dataIn->readInt());
+        info->setNetworkBrokerId(Pointer<BrokerId>(dynamic_cast<BrokerId* >(
+            tightUnmarshalCachedObject(wireFormat, dataIn, bs))));
     }
-    AMQ_CATCH_RETHROW( decaf::io::IOException )
-    AMQ_CATCH_EXCEPTION_CONVERT( exceptions::ActiveMQException, decaf::io::IOException )
-    AMQ_CATCHALL_THROW( decaf::io::IOException )
+    AMQ_CATCH_RETHROW(decaf::io::IOException)
+    AMQ_CATCH_EXCEPTION_CONVERT(exceptions::ActiveMQException, decaf::io::IOException)
+    AMQ_CATCHALL_THROW(decaf::io::IOException)
 }
 
 ///////////////////////////////////////////////////////////////////////////////
-int NetworkBridgeFilterMarshaller::tightMarshal1( OpenWireFormat* wireFormat, DataStructure* dataStructure, BooleanStream* bs ) {
+int NetworkBridgeFilterMarshaller::tightMarshal1(OpenWireFormat* wireFormat, DataStructure* dataStructure, BooleanStream* bs) {
 
     try {
 
         NetworkBridgeFilter* info =
-            dynamic_cast<NetworkBridgeFilter*>( dataStructure );
+            dynamic_cast<NetworkBridgeFilter*>(dataStructure);
 
-        int rc = BaseDataStreamMarshaller::tightMarshal1( wireFormat, dataStructure, bs );
-        rc += tightMarshalCachedObject1( wireFormat, info->getNetworkBrokerId().get(), bs );
+        int rc = BaseDataStreamMarshaller::tightMarshal1(wireFormat, dataStructure, bs);
+        rc += tightMarshalCachedObject1(wireFormat, info->getNetworkBrokerId().get(), bs);
 
         return rc + 4;
     }
-    AMQ_CATCH_RETHROW( decaf::io::IOException )
-    AMQ_CATCH_EXCEPTION_CONVERT( exceptions::ActiveMQException, decaf::io::IOException )
-    AMQ_CATCHALL_THROW( decaf::io::IOException )
+    AMQ_CATCH_RETHROW(decaf::io::IOException)
+    AMQ_CATCH_EXCEPTION_CONVERT(exceptions::ActiveMQException, decaf::io::IOException)
+    AMQ_CATCHALL_THROW(decaf::io::IOException)
 }
 
 ///////////////////////////////////////////////////////////////////////////////
-void NetworkBridgeFilterMarshaller::tightMarshal2( OpenWireFormat* wireFormat, DataStructure* dataStructure, DataOutputStream* dataOut, BooleanStream* bs ) {
+void NetworkBridgeFilterMarshaller::tightMarshal2(OpenWireFormat* wireFormat, DataStructure* dataStructure, DataOutputStream* dataOut, BooleanStream* bs) {
 
     try {
 
-        BaseDataStreamMarshaller::tightMarshal2( wireFormat, dataStructure, dataOut, bs );
+        BaseDataStreamMarshaller::tightMarshal2(wireFormat, dataStructure, dataOut, bs );
 
         NetworkBridgeFilter* info =
-            dynamic_cast<NetworkBridgeFilter*>( dataStructure );
-        dataOut->writeInt( info->getNetworkTTL() );
-        tightMarshalCachedObject2( wireFormat, info->getNetworkBrokerId().get(), dataOut, bs );
+            dynamic_cast<NetworkBridgeFilter*>(dataStructure);
+        dataOut->writeInt(info->getNetworkTTL());
+        tightMarshalCachedObject2(wireFormat, info->getNetworkBrokerId().get(), dataOut, bs);
     }
-    AMQ_CATCH_RETHROW( decaf::io::IOException )
-    AMQ_CATCH_EXCEPTION_CONVERT( exceptions::ActiveMQException, decaf::io::IOException )
-    AMQ_CATCHALL_THROW( decaf::io::IOException )
+    AMQ_CATCH_RETHROW(decaf::io::IOException)
+    AMQ_CATCH_EXCEPTION_CONVERT( exceptions::ActiveMQException, decaf::io::IOException)
+    AMQ_CATCHALL_THROW(decaf::io::IOException)
 }
 
 ///////////////////////////////////////////////////////////////////////////////
-void NetworkBridgeFilterMarshaller::looseUnmarshal( OpenWireFormat* wireFormat, DataStructure* dataStructure, DataInputStream* dataIn ) {
+void NetworkBridgeFilterMarshaller::looseUnmarshal(OpenWireFormat* wireFormat, DataStructure* dataStructure, DataInputStream* dataIn) {
 
     try {
 
-        BaseDataStreamMarshaller::looseUnmarshal( wireFormat, dataStructure, dataIn );
+        BaseDataStreamMarshaller::looseUnmarshal(wireFormat, dataStructure, dataIn);
         NetworkBridgeFilter* info =
-            dynamic_cast<NetworkBridgeFilter*>( dataStructure );
-        info->setNetworkTTL( dataIn->readInt() );
-        info->setNetworkBrokerId( Pointer<BrokerId>( dynamic_cast< BrokerId* >( 
-            looseUnmarshalCachedObject( wireFormat, dataIn ) ) ) );
+            dynamic_cast<NetworkBridgeFilter*>(dataStructure);
+        info->setNetworkTTL(dataIn->readInt());
+        info->setNetworkBrokerId(Pointer<BrokerId>(dynamic_cast<BrokerId*>(
+            looseUnmarshalCachedObject(wireFormat, dataIn))));
     }
-    AMQ_CATCH_RETHROW( decaf::io::IOException )
-    AMQ_CATCH_EXCEPTION_CONVERT( exceptions::ActiveMQException, decaf::io::IOException )
-    AMQ_CATCHALL_THROW( decaf::io::IOException )
+    AMQ_CATCH_RETHROW(decaf::io::IOException)
+    AMQ_CATCH_EXCEPTION_CONVERT(exceptions::ActiveMQException, decaf::io::IOException)
+    AMQ_CATCHALL_THROW(decaf::io::IOException)
 }
 
 ///////////////////////////////////////////////////////////////////////////////
-void NetworkBridgeFilterMarshaller::looseMarshal( OpenWireFormat* wireFormat, DataStructure* dataStructure, DataOutputStream* dataOut ) {
+void NetworkBridgeFilterMarshaller::looseMarshal(OpenWireFormat* wireFormat, DataStructure* dataStructure, DataOutputStream* dataOut) {
 
     try {
 
         NetworkBridgeFilter* info =
-            dynamic_cast<NetworkBridgeFilter*>( dataStructure );
-        BaseDataStreamMarshaller::looseMarshal( wireFormat, dataStructure, dataOut );
-        dataOut->writeInt( info->getNetworkTTL() );
-        looseMarshalCachedObject( wireFormat, info->getNetworkBrokerId().get(), dataOut );
+            dynamic_cast<NetworkBridgeFilter*>(dataStructure);
+        BaseDataStreamMarshaller::looseMarshal(wireFormat, dataStructure, dataOut);
+        dataOut->writeInt(info->getNetworkTTL());
+        looseMarshalCachedObject(wireFormat, info->getNetworkBrokerId().get(), dataOut);
     }
-    AMQ_CATCH_RETHROW( decaf::io::IOException )
-    AMQ_CATCH_EXCEPTION_CONVERT( exceptions::ActiveMQException, decaf::io::IOException )
-    AMQ_CATCHALL_THROW( decaf::io::IOException )
+    AMQ_CATCH_RETHROW(decaf::io::IOException)
+    AMQ_CATCH_EXCEPTION_CONVERT(exceptions::ActiveMQException, decaf::io::IOException)
+    AMQ_CATCHALL_THROW(decaf::io::IOException)
 }
 

Modified: activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/wireformat/openwire/marshal/generated/NetworkBridgeFilterMarshaller.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/wireformat/openwire/marshal/generated/NetworkBridgeFilterMarshaller.h?rev=1460467&r1=1460466&r2=1460467&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/wireformat/openwire/marshal/generated/NetworkBridgeFilterMarshaller.h (original)
+++ activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/wireformat/openwire/marshal/generated/NetworkBridgeFilterMarshaller.h Sun Mar 24 21:30:52 2013
@@ -33,11 +33,11 @@
 #include <activemq/wireformat/openwire/OpenWireFormat.h>
 #include <activemq/wireformat/openwire/utils/BooleanStream.h>
 
-namespace activemq{
-namespace wireformat{
-namespace openwire{
-namespace marshal{
-namespace generated{
+namespace activemq {
+namespace wireformat {
+namespace openwire {
+namespace marshal {
+namespace generated {
 
     /**
      * Marshaling code for Open Wire Format for NetworkBridgeFilterMarshaller
@@ -56,27 +56,27 @@ namespace generated{
 
         virtual unsigned char getDataStructureType() const;
 
-        virtual void tightUnmarshal( OpenWireFormat* wireFormat,
-                                     commands::DataStructure* dataStructure,
-                                     decaf::io::DataInputStream* dataIn,
-                                     utils::BooleanStream* bs );
+        virtual void tightUnmarshal(OpenWireFormat* wireFormat,
+                                    commands::DataStructure* dataStructure,
+                                    decaf::io::DataInputStream* dataIn,
+                                    utils::BooleanStream* bs);
+
+        virtual int tightMarshal1(OpenWireFormat* wireFormat,
+                                  commands::DataStructure* dataStructure,
+                                  utils::BooleanStream* bs);
 
-        virtual int tightMarshal1( OpenWireFormat* wireFormat,
+        virtual void tightMarshal2(OpenWireFormat* wireFormat,
                                    commands::DataStructure* dataStructure,
-                                   utils::BooleanStream* bs );
+                                   decaf::io::DataOutputStream* dataOut,
+                                   utils::BooleanStream* bs);
 
-        virtual void tightMarshal2( OpenWireFormat* wireFormat,
+        virtual void looseUnmarshal(OpenWireFormat* wireFormat,
                                     commands::DataStructure* dataStructure,
-                                    decaf::io::DataOutputStream* dataOut,
-                                    utils::BooleanStream* bs );
+                                    decaf::io::DataInputStream* dataIn);
 
-        virtual void looseUnmarshal( OpenWireFormat* wireFormat,
-                                     commands::DataStructure* dataStructure,
-                                     decaf::io::DataInputStream* dataIn );
-
-        virtual void looseMarshal( OpenWireFormat* wireFormat,
-                                   commands::DataStructure* dataStructure,
-                                   decaf::io::DataOutputStream* dataOut );
+        virtual void looseMarshal(OpenWireFormat* wireFormat,
+                                  commands::DataStructure* dataStructure,
+                                  decaf::io::DataOutputStream* dataOut);
 
     };
 

Modified: activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/wireformat/openwire/marshal/generated/PartialCommandMarshaller.cpp
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/wireformat/openwire/marshal/generated/PartialCommandMarshaller.cpp?rev=1460467&r1=1460466&r2=1460467&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/wireformat/openwire/marshal/generated/PartialCommandMarshaller.cpp (original)
+++ activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/wireformat/openwire/marshal/generated/PartialCommandMarshaller.cpp Sun Mar 24 21:30:52 2013
@@ -51,94 +51,94 @@ unsigned char PartialCommandMarshaller::
 }
 
 ///////////////////////////////////////////////////////////////////////////////
-void PartialCommandMarshaller::tightUnmarshal( OpenWireFormat* wireFormat, DataStructure* dataStructure, DataInputStream* dataIn, BooleanStream* bs ) {
+void PartialCommandMarshaller::tightUnmarshal(OpenWireFormat* wireFormat, DataStructure* dataStructure, DataInputStream* dataIn, BooleanStream* bs) {
 
     try {
 
-        BaseDataStreamMarshaller::tightUnmarshal( wireFormat, dataStructure, dataIn, bs );
+        BaseDataStreamMarshaller::tightUnmarshal(wireFormat, dataStructure, dataIn, bs);
 
         PartialCommand* info =
-            dynamic_cast<PartialCommand*>( dataStructure );
-        info->setCommandId( dataIn->readInt() );
-        info->setData( tightUnmarshalByteArray( dataIn, bs ) );
+            dynamic_cast<PartialCommand*>(dataStructure);
+        info->setCommandId(dataIn->readInt());
+        info->setData(tightUnmarshalByteArray(dataIn, bs));
     }
-    AMQ_CATCH_RETHROW( decaf::io::IOException )
-    AMQ_CATCH_EXCEPTION_CONVERT( exceptions::ActiveMQException, decaf::io::IOException )
-    AMQ_CATCHALL_THROW( decaf::io::IOException )
+    AMQ_CATCH_RETHROW(decaf::io::IOException)
+    AMQ_CATCH_EXCEPTION_CONVERT(exceptions::ActiveMQException, decaf::io::IOException)
+    AMQ_CATCHALL_THROW(decaf::io::IOException)
 }
 
 ///////////////////////////////////////////////////////////////////////////////
-int PartialCommandMarshaller::tightMarshal1( OpenWireFormat* wireFormat, DataStructure* dataStructure, BooleanStream* bs ) {
+int PartialCommandMarshaller::tightMarshal1(OpenWireFormat* wireFormat, DataStructure* dataStructure, BooleanStream* bs) {
 
     try {
 
         PartialCommand* info =
-            dynamic_cast<PartialCommand*>( dataStructure );
+            dynamic_cast<PartialCommand*>(dataStructure);
 
-        int rc = BaseDataStreamMarshaller::tightMarshal1( wireFormat, dataStructure, bs );
-        bs->writeBoolean( info->getData().size() != 0 );
+        int rc = BaseDataStreamMarshaller::tightMarshal1(wireFormat, dataStructure, bs);
+        bs->writeBoolean(info->getData().size() != 0);
         rc += info->getData().size() == 0 ? 0 : (int)info->getData().size() + 4;
 
         return rc + 4;
     }
-    AMQ_CATCH_RETHROW( decaf::io::IOException )
-    AMQ_CATCH_EXCEPTION_CONVERT( exceptions::ActiveMQException, decaf::io::IOException )
-    AMQ_CATCHALL_THROW( decaf::io::IOException )
+    AMQ_CATCH_RETHROW(decaf::io::IOException)
+    AMQ_CATCH_EXCEPTION_CONVERT(exceptions::ActiveMQException, decaf::io::IOException)
+    AMQ_CATCHALL_THROW(decaf::io::IOException)
 }
 
 ///////////////////////////////////////////////////////////////////////////////
-void PartialCommandMarshaller::tightMarshal2( OpenWireFormat* wireFormat, DataStructure* dataStructure, DataOutputStream* dataOut, BooleanStream* bs ) {
+void PartialCommandMarshaller::tightMarshal2(OpenWireFormat* wireFormat, DataStructure* dataStructure, DataOutputStream* dataOut, BooleanStream* bs) {
 
     try {
 
-        BaseDataStreamMarshaller::tightMarshal2( wireFormat, dataStructure, dataOut, bs );
+        BaseDataStreamMarshaller::tightMarshal2(wireFormat, dataStructure, dataOut, bs );
 
         PartialCommand* info =
-            dynamic_cast<PartialCommand*>( dataStructure );
-        dataOut->writeInt( info->getCommandId() );
-        if( bs->readBoolean() ) {
-            dataOut->writeInt( (int)info->getData().size() );
-            dataOut->write( (const unsigned char*)(&info->getData()[0]), (int)info->getData().size(), 0, (int)info->getData().size() );
+            dynamic_cast<PartialCommand*>(dataStructure);
+        dataOut->writeInt(info->getCommandId());
+        if (bs->readBoolean()) {
+            dataOut->writeInt((int)info->getData().size() );
+            dataOut->write((const unsigned char*)(&info->getData()[0]), (int)info->getData().size(), 0, (int)info->getData().size());
         }
     }
-    AMQ_CATCH_RETHROW( decaf::io::IOException )
-    AMQ_CATCH_EXCEPTION_CONVERT( exceptions::ActiveMQException, decaf::io::IOException )
-    AMQ_CATCHALL_THROW( decaf::io::IOException )
+    AMQ_CATCH_RETHROW(decaf::io::IOException)
+    AMQ_CATCH_EXCEPTION_CONVERT( exceptions::ActiveMQException, decaf::io::IOException)
+    AMQ_CATCHALL_THROW(decaf::io::IOException)
 }
 
 ///////////////////////////////////////////////////////////////////////////////
-void PartialCommandMarshaller::looseUnmarshal( OpenWireFormat* wireFormat, DataStructure* dataStructure, DataInputStream* dataIn ) {
+void PartialCommandMarshaller::looseUnmarshal(OpenWireFormat* wireFormat, DataStructure* dataStructure, DataInputStream* dataIn) {
 
     try {
 
-        BaseDataStreamMarshaller::looseUnmarshal( wireFormat, dataStructure, dataIn );
+        BaseDataStreamMarshaller::looseUnmarshal(wireFormat, dataStructure, dataIn);
         PartialCommand* info =
-            dynamic_cast<PartialCommand*>( dataStructure );
-        info->setCommandId( dataIn->readInt() );
-        info->setData( looseUnmarshalByteArray( dataIn ) );
+            dynamic_cast<PartialCommand*>(dataStructure);
+        info->setCommandId(dataIn->readInt());
+        info->setData(looseUnmarshalByteArray(dataIn));
     }
-    AMQ_CATCH_RETHROW( decaf::io::IOException )
-    AMQ_CATCH_EXCEPTION_CONVERT( exceptions::ActiveMQException, decaf::io::IOException )
-    AMQ_CATCHALL_THROW( decaf::io::IOException )
+    AMQ_CATCH_RETHROW(decaf::io::IOException)
+    AMQ_CATCH_EXCEPTION_CONVERT(exceptions::ActiveMQException, decaf::io::IOException)
+    AMQ_CATCHALL_THROW(decaf::io::IOException)
 }
 
 ///////////////////////////////////////////////////////////////////////////////
-void PartialCommandMarshaller::looseMarshal( OpenWireFormat* wireFormat, DataStructure* dataStructure, DataOutputStream* dataOut ) {
+void PartialCommandMarshaller::looseMarshal(OpenWireFormat* wireFormat, DataStructure* dataStructure, DataOutputStream* dataOut) {
 
     try {
 
         PartialCommand* info =
-            dynamic_cast<PartialCommand*>( dataStructure );
-        BaseDataStreamMarshaller::looseMarshal( wireFormat, dataStructure, dataOut );
-        dataOut->writeInt( info->getCommandId() );
+            dynamic_cast<PartialCommand*>(dataStructure);
+        BaseDataStreamMarshaller::looseMarshal(wireFormat, dataStructure, dataOut);
+        dataOut->writeInt(info->getCommandId());
         dataOut->write( info->getData().size() != 0 );
         if( info->getData().size() != 0 ) {
             dataOut->writeInt( (int)info->getData().size() );
-            dataOut->write( (const unsigned char*)(&info->getData()[0]), (int)info->getData().size(), 0, (int)info->getData().size() );
+            dataOut->write((const unsigned char*)(&info->getData()[0]), (int)info->getData().size(), 0, (int)info->getData().size());
         }
     }
-    AMQ_CATCH_RETHROW( decaf::io::IOException )
-    AMQ_CATCH_EXCEPTION_CONVERT( exceptions::ActiveMQException, decaf::io::IOException )
-    AMQ_CATCHALL_THROW( decaf::io::IOException )
+    AMQ_CATCH_RETHROW(decaf::io::IOException)
+    AMQ_CATCH_EXCEPTION_CONVERT(exceptions::ActiveMQException, decaf::io::IOException)
+    AMQ_CATCHALL_THROW(decaf::io::IOException)
 }
 

Modified: activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/wireformat/openwire/marshal/generated/PartialCommandMarshaller.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/wireformat/openwire/marshal/generated/PartialCommandMarshaller.h?rev=1460467&r1=1460466&r2=1460467&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/wireformat/openwire/marshal/generated/PartialCommandMarshaller.h (original)
+++ activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/wireformat/openwire/marshal/generated/PartialCommandMarshaller.h Sun Mar 24 21:30:52 2013
@@ -33,11 +33,11 @@
 #include <activemq/wireformat/openwire/OpenWireFormat.h>
 #include <activemq/wireformat/openwire/utils/BooleanStream.h>
 
-namespace activemq{
-namespace wireformat{
-namespace openwire{
-namespace marshal{
-namespace generated{
+namespace activemq {
+namespace wireformat {
+namespace openwire {
+namespace marshal {
+namespace generated {
 
     /**
      * Marshaling code for Open Wire Format for PartialCommandMarshaller
@@ -56,27 +56,27 @@ namespace generated{
 
         virtual unsigned char getDataStructureType() const;
 
-        virtual void tightUnmarshal( OpenWireFormat* wireFormat,
-                                     commands::DataStructure* dataStructure,
-                                     decaf::io::DataInputStream* dataIn,
-                                     utils::BooleanStream* bs );
+        virtual void tightUnmarshal(OpenWireFormat* wireFormat,
+                                    commands::DataStructure* dataStructure,
+                                    decaf::io::DataInputStream* dataIn,
+                                    utils::BooleanStream* bs);
+
+        virtual int tightMarshal1(OpenWireFormat* wireFormat,
+                                  commands::DataStructure* dataStructure,
+                                  utils::BooleanStream* bs);
 
-        virtual int tightMarshal1( OpenWireFormat* wireFormat,
+        virtual void tightMarshal2(OpenWireFormat* wireFormat,
                                    commands::DataStructure* dataStructure,
-                                   utils::BooleanStream* bs );
+                                   decaf::io::DataOutputStream* dataOut,
+                                   utils::BooleanStream* bs);
 
-        virtual void tightMarshal2( OpenWireFormat* wireFormat,
+        virtual void looseUnmarshal(OpenWireFormat* wireFormat,
                                     commands::DataStructure* dataStructure,
-                                    decaf::io::DataOutputStream* dataOut,
-                                    utils::BooleanStream* bs );
+                                    decaf::io::DataInputStream* dataIn);
 
-        virtual void looseUnmarshal( OpenWireFormat* wireFormat,
-                                     commands::DataStructure* dataStructure,
-                                     decaf::io::DataInputStream* dataIn );
-
-        virtual void looseMarshal( OpenWireFormat* wireFormat,
-                                   commands::DataStructure* dataStructure,
-                                   decaf::io::DataOutputStream* dataOut );
+        virtual void looseMarshal(OpenWireFormat* wireFormat,
+                                  commands::DataStructure* dataStructure,
+                                  decaf::io::DataOutputStream* dataOut);
 
     };
 

Modified: activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/wireformat/openwire/marshal/generated/ProducerAckMarshaller.cpp
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/wireformat/openwire/marshal/generated/ProducerAckMarshaller.cpp?rev=1460467&r1=1460466&r2=1460467&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/wireformat/openwire/marshal/generated/ProducerAckMarshaller.cpp (original)
+++ activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/wireformat/openwire/marshal/generated/ProducerAckMarshaller.cpp Sun Mar 24 21:30:52 2013
@@ -51,123 +51,123 @@ unsigned char ProducerAckMarshaller::get
 }
 
 ///////////////////////////////////////////////////////////////////////////////
-void ProducerAckMarshaller::tightUnmarshal( OpenWireFormat* wireFormat, DataStructure* dataStructure, DataInputStream* dataIn, BooleanStream* bs ) {
+void ProducerAckMarshaller::tightUnmarshal(OpenWireFormat* wireFormat, DataStructure* dataStructure, DataInputStream* dataIn, BooleanStream* bs) {
 
     try {
 
-        BaseCommandMarshaller::tightUnmarshal( wireFormat, dataStructure, dataIn, bs );
+        BaseCommandMarshaller::tightUnmarshal(wireFormat, dataStructure, dataIn, bs);
 
         ProducerAck* info =
-            dynamic_cast<ProducerAck*>( dataStructure );
+            dynamic_cast<ProducerAck*>(dataStructure);
 
         int wireVersion = wireFormat->getVersion();
 
-        if( wireVersion >= 3 ) {
-            info->setProducerId( Pointer<ProducerId>( dynamic_cast< ProducerId* >(
-                tightUnmarshalNestedObject( wireFormat, dataIn, bs ) ) ) );
+        if (wireVersion >= 3) {
+            info->setProducerId(Pointer<ProducerId>(dynamic_cast<ProducerId* >(
+                tightUnmarshalNestedObject(wireFormat, dataIn, bs))));
         }
-        if( wireVersion >= 3 ) {
-            info->setSize( dataIn->readInt() );
+        if (wireVersion >= 3) {
+            info->setSize(dataIn->readInt());
         }
     }
-    AMQ_CATCH_RETHROW( decaf::io::IOException )
-    AMQ_CATCH_EXCEPTION_CONVERT( exceptions::ActiveMQException, decaf::io::IOException )
-    AMQ_CATCHALL_THROW( decaf::io::IOException )
+    AMQ_CATCH_RETHROW(decaf::io::IOException)
+    AMQ_CATCH_EXCEPTION_CONVERT(exceptions::ActiveMQException, decaf::io::IOException)
+    AMQ_CATCHALL_THROW(decaf::io::IOException)
 }
 
 ///////////////////////////////////////////////////////////////////////////////
-int ProducerAckMarshaller::tightMarshal1( OpenWireFormat* wireFormat, DataStructure* dataStructure, BooleanStream* bs ) {
+int ProducerAckMarshaller::tightMarshal1(OpenWireFormat* wireFormat, DataStructure* dataStructure, BooleanStream* bs) {
 
     try {
 
         ProducerAck* info =
-            dynamic_cast<ProducerAck*>( dataStructure );
+            dynamic_cast<ProducerAck*>(dataStructure);
 
-        int rc = BaseCommandMarshaller::tightMarshal1( wireFormat, dataStructure, bs );
+        int rc = BaseCommandMarshaller::tightMarshal1(wireFormat, dataStructure, bs);
 
         int wireVersion = wireFormat->getVersion();
 
-        if( wireVersion >= 3 ) {
-            rc += tightMarshalNestedObject1( wireFormat, info->getProducerId().get(), bs );
+        if (wireVersion >= 3) {
+            rc += tightMarshalNestedObject1(wireFormat, info->getProducerId().get(), bs);
         }
-        if( wireVersion >= 3 ) {
+        if (wireVersion >= 3) {
         }
 
         return rc + 4;
     }
-    AMQ_CATCH_RETHROW( decaf::io::IOException )
-    AMQ_CATCH_EXCEPTION_CONVERT( exceptions::ActiveMQException, decaf::io::IOException )
-    AMQ_CATCHALL_THROW( decaf::io::IOException )
+    AMQ_CATCH_RETHROW(decaf::io::IOException)
+    AMQ_CATCH_EXCEPTION_CONVERT(exceptions::ActiveMQException, decaf::io::IOException)
+    AMQ_CATCHALL_THROW(decaf::io::IOException)
 }
 
 ///////////////////////////////////////////////////////////////////////////////
-void ProducerAckMarshaller::tightMarshal2( OpenWireFormat* wireFormat, DataStructure* dataStructure, DataOutputStream* dataOut, BooleanStream* bs ) {
+void ProducerAckMarshaller::tightMarshal2(OpenWireFormat* wireFormat, DataStructure* dataStructure, DataOutputStream* dataOut, BooleanStream* bs) {
 
     try {
 
-        BaseCommandMarshaller::tightMarshal2( wireFormat, dataStructure, dataOut, bs );
+        BaseCommandMarshaller::tightMarshal2(wireFormat, dataStructure, dataOut, bs );
 
         ProducerAck* info =
-            dynamic_cast<ProducerAck*>( dataStructure );
+            dynamic_cast<ProducerAck*>(dataStructure);
 
         int wireVersion = wireFormat->getVersion();
 
-        if( wireVersion >= 3 ) {
-            tightMarshalNestedObject2( wireFormat, info->getProducerId().get(), dataOut, bs );
+        if (wireVersion >= 3) {
+            tightMarshalNestedObject2(wireFormat, info->getProducerId().get(), dataOut, bs);
         }
-        if( wireVersion >= 3 ) {
-            dataOut->writeInt( info->getSize() );
+        if (wireVersion >= 3) {
+            dataOut->writeInt(info->getSize());
         }
     }
-    AMQ_CATCH_RETHROW( decaf::io::IOException )
-    AMQ_CATCH_EXCEPTION_CONVERT( exceptions::ActiveMQException, decaf::io::IOException )
-    AMQ_CATCHALL_THROW( decaf::io::IOException )
+    AMQ_CATCH_RETHROW(decaf::io::IOException)
+    AMQ_CATCH_EXCEPTION_CONVERT( exceptions::ActiveMQException, decaf::io::IOException)
+    AMQ_CATCHALL_THROW(decaf::io::IOException)
 }
 
 ///////////////////////////////////////////////////////////////////////////////
-void ProducerAckMarshaller::looseUnmarshal( OpenWireFormat* wireFormat, DataStructure* dataStructure, DataInputStream* dataIn ) {
+void ProducerAckMarshaller::looseUnmarshal(OpenWireFormat* wireFormat, DataStructure* dataStructure, DataInputStream* dataIn) {
 
     try {
 
-        BaseCommandMarshaller::looseUnmarshal( wireFormat, dataStructure, dataIn );
+        BaseCommandMarshaller::looseUnmarshal(wireFormat, dataStructure, dataIn);
         ProducerAck* info =
-            dynamic_cast<ProducerAck*>( dataStructure );
+            dynamic_cast<ProducerAck*>(dataStructure);
 
         int wireVersion = wireFormat->getVersion();
 
-        if( wireVersion >= 3 ) {
-            info->setProducerId( Pointer<ProducerId>( dynamic_cast< ProducerId* >( 
-                looseUnmarshalNestedObject( wireFormat, dataIn ) ) ) );
+        if (wireVersion >= 3) {
+            info->setProducerId(Pointer<ProducerId>(dynamic_cast<ProducerId*>(
+                looseUnmarshalNestedObject(wireFormat, dataIn))));
         }
-        if( wireVersion >= 3 ) {
-            info->setSize( dataIn->readInt() );
+        if (wireVersion >= 3) {
+            info->setSize(dataIn->readInt());
         }
     }
-    AMQ_CATCH_RETHROW( decaf::io::IOException )
-    AMQ_CATCH_EXCEPTION_CONVERT( exceptions::ActiveMQException, decaf::io::IOException )
-    AMQ_CATCHALL_THROW( decaf::io::IOException )
+    AMQ_CATCH_RETHROW(decaf::io::IOException)
+    AMQ_CATCH_EXCEPTION_CONVERT(exceptions::ActiveMQException, decaf::io::IOException)
+    AMQ_CATCHALL_THROW(decaf::io::IOException)
 }
 
 ///////////////////////////////////////////////////////////////////////////////
-void ProducerAckMarshaller::looseMarshal( OpenWireFormat* wireFormat, DataStructure* dataStructure, DataOutputStream* dataOut ) {
+void ProducerAckMarshaller::looseMarshal(OpenWireFormat* wireFormat, DataStructure* dataStructure, DataOutputStream* dataOut) {
 
     try {
 
         ProducerAck* info =
-            dynamic_cast<ProducerAck*>( dataStructure );
-        BaseCommandMarshaller::looseMarshal( wireFormat, dataStructure, dataOut );
+            dynamic_cast<ProducerAck*>(dataStructure);
+        BaseCommandMarshaller::looseMarshal(wireFormat, dataStructure, dataOut);
 
         int wireVersion = wireFormat->getVersion();
 
-        if( wireVersion >= 3 ) {
-            looseMarshalNestedObject( wireFormat, info->getProducerId().get(), dataOut );
+        if (wireVersion >= 3) {
+            looseMarshalNestedObject(wireFormat, info->getProducerId().get(), dataOut);
         }
-        if( wireVersion >= 3 ) {
-            dataOut->writeInt( info->getSize() );
+        if (wireVersion >= 3) {
+            dataOut->writeInt(info->getSize());
         }
     }
-    AMQ_CATCH_RETHROW( decaf::io::IOException )
-    AMQ_CATCH_EXCEPTION_CONVERT( exceptions::ActiveMQException, decaf::io::IOException )
-    AMQ_CATCHALL_THROW( decaf::io::IOException )
+    AMQ_CATCH_RETHROW(decaf::io::IOException)
+    AMQ_CATCH_EXCEPTION_CONVERT(exceptions::ActiveMQException, decaf::io::IOException)
+    AMQ_CATCHALL_THROW(decaf::io::IOException)
 }
 

Modified: activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/wireformat/openwire/marshal/generated/ProducerAckMarshaller.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/wireformat/openwire/marshal/generated/ProducerAckMarshaller.h?rev=1460467&r1=1460466&r2=1460467&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/wireformat/openwire/marshal/generated/ProducerAckMarshaller.h (original)
+++ activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/wireformat/openwire/marshal/generated/ProducerAckMarshaller.h Sun Mar 24 21:30:52 2013
@@ -33,11 +33,11 @@
 #include <activemq/wireformat/openwire/OpenWireFormat.h>
 #include <activemq/wireformat/openwire/utils/BooleanStream.h>
 
-namespace activemq{
-namespace wireformat{
-namespace openwire{
-namespace marshal{
-namespace generated{
+namespace activemq {
+namespace wireformat {
+namespace openwire {
+namespace marshal {
+namespace generated {
 
     /**
      * Marshaling code for Open Wire Format for ProducerAckMarshaller
@@ -56,27 +56,27 @@ namespace generated{
 
         virtual unsigned char getDataStructureType() const;
 
-        virtual void tightUnmarshal( OpenWireFormat* wireFormat,
-                                     commands::DataStructure* dataStructure,
-                                     decaf::io::DataInputStream* dataIn,
-                                     utils::BooleanStream* bs );
+        virtual void tightUnmarshal(OpenWireFormat* wireFormat,
+                                    commands::DataStructure* dataStructure,
+                                    decaf::io::DataInputStream* dataIn,
+                                    utils::BooleanStream* bs);
+
+        virtual int tightMarshal1(OpenWireFormat* wireFormat,
+                                  commands::DataStructure* dataStructure,
+                                  utils::BooleanStream* bs);
 
-        virtual int tightMarshal1( OpenWireFormat* wireFormat,
+        virtual void tightMarshal2(OpenWireFormat* wireFormat,
                                    commands::DataStructure* dataStructure,
-                                   utils::BooleanStream* bs );
+                                   decaf::io::DataOutputStream* dataOut,
+                                   utils::BooleanStream* bs);
 
-        virtual void tightMarshal2( OpenWireFormat* wireFormat,
+        virtual void looseUnmarshal(OpenWireFormat* wireFormat,
                                     commands::DataStructure* dataStructure,
-                                    decaf::io::DataOutputStream* dataOut,
-                                    utils::BooleanStream* bs );
+                                    decaf::io::DataInputStream* dataIn);
 
-        virtual void looseUnmarshal( OpenWireFormat* wireFormat,
-                                     commands::DataStructure* dataStructure,
-                                     decaf::io::DataInputStream* dataIn );
-
-        virtual void looseMarshal( OpenWireFormat* wireFormat,
-                                   commands::DataStructure* dataStructure,
-                                   decaf::io::DataOutputStream* dataOut );
+        virtual void looseMarshal(OpenWireFormat* wireFormat,
+                                  commands::DataStructure* dataStructure,
+                                  decaf::io::DataOutputStream* dataOut);
 
     };