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 2007/10/17 19:35:11 UTC

svn commit: r585591 [1/2] - in /activemq/activemq-cpp/trunk/src: main/activemq/connector/openwire/ main/activemq/connector/openwire/commands/ main/java/org/apache/activemq/openwire/tool/ test/activemq/connector/openwire/commands/

Author: tabish
Date: Wed Oct 17 10:35:05 2007
New Revision: 585591

URL: http://svn.apache.org/viewvc?rev=585591&view=rev
Log:
https://issues.apache.org/activemq/browse/AMQCPP-139

Make the cloneDataStructure methods return covarient return types to eliminate as many dynamic casts from the OpenWireConnector as possible.

Modified:
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/OpenWireConnector.cpp
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ActiveMQBytesMessage.h
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ActiveMQDestination.h
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ActiveMQMapMessage.h
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ActiveMQMessage.h
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ActiveMQObjectMessage.h
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ActiveMQQueue.h
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ActiveMQStreamMessage.h
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ActiveMQTempDestination.h
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ActiveMQTempQueue.h
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ActiveMQTempTopic.h
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ActiveMQTextMessage.h
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ActiveMQTopic.h
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/BrokerId.cpp
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/BrokerId.h
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/BrokerInfo.cpp
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/BrokerInfo.h
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ConnectionControl.cpp
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ConnectionControl.h
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ConnectionError.cpp
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ConnectionError.h
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ConnectionId.cpp
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ConnectionId.h
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ConnectionInfo.cpp
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ConnectionInfo.h
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ConsumerControl.cpp
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ConsumerControl.h
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ConsumerId.cpp
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ConsumerId.h
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ConsumerInfo.cpp
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ConsumerInfo.h
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ControlCommand.cpp
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ControlCommand.h
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/DataArrayResponse.cpp
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/DataArrayResponse.h
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/DataResponse.cpp
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/DataResponse.h
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/DestinationInfo.cpp
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/DestinationInfo.h
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/DiscoveryEvent.cpp
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/DiscoveryEvent.h
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ExceptionResponse.cpp
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ExceptionResponse.h
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/FlushCommand.cpp
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/FlushCommand.h
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/IntegerResponse.cpp
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/IntegerResponse.h
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/JournalQueueAck.cpp
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/JournalQueueAck.h
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/JournalTopicAck.cpp
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/JournalTopicAck.h
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/JournalTrace.cpp
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/JournalTrace.h
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/JournalTransaction.cpp
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/JournalTransaction.h
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/KeepAliveInfo.cpp
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/KeepAliveInfo.h
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/LastPartialCommand.cpp
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/LastPartialCommand.h
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/LocalTransactionId.cpp
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/LocalTransactionId.h
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/Message.cpp
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/Message.h
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/MessageAck.cpp
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/MessageAck.h
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/MessageDispatch.cpp
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/MessageDispatch.h
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/MessageDispatchNotification.cpp
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/MessageDispatchNotification.h
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/MessageId.cpp
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/MessageId.h
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/MessagePull.cpp
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/MessagePull.h
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/NetworkBridgeFilter.cpp
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/NetworkBridgeFilter.h
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/PartialCommand.cpp
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/PartialCommand.h
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ProducerId.cpp
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ProducerId.h
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ProducerInfo.cpp
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ProducerInfo.h
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/RemoveInfo.cpp
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/RemoveInfo.h
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/RemoveSubscriptionInfo.cpp
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/RemoveSubscriptionInfo.h
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ReplayCommand.cpp
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ReplayCommand.h
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/Response.cpp
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/Response.h
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/SessionId.cpp
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/SessionId.h
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/SessionInfo.cpp
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/SessionInfo.h
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ShutdownInfo.cpp
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ShutdownInfo.h
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/SubscriptionInfo.cpp
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/SubscriptionInfo.h
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/TransactionId.cpp
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/TransactionId.h
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/TransactionInfo.cpp
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/TransactionInfo.h
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/XATransactionId.cpp
    activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/XATransactionId.h
    activemq/activemq-cpp/trunk/src/main/java/org/apache/activemq/openwire/tool/AmqCppClassesGenerator.java
    activemq/activemq-cpp/trunk/src/main/java/org/apache/activemq/openwire/tool/AmqCppHeadersGenerator.java
    activemq/activemq-cpp/trunk/src/test/activemq/connector/openwire/commands/ActiveMQDestinationTest2.h

Modified: activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/OpenWireConnector.cpp
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/OpenWireConnector.cpp?rev=585591&r1=585590&r2=585591&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/OpenWireConnector.cpp (original)
+++ activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/OpenWireConnector.cpp Wed Oct 17 10:35:05 2007
@@ -554,9 +554,7 @@
                 "Destination was either NULL or not created by this OpenWireConnector" );
         }
 
-        consumerInfo->setDestination(
-            dynamic_cast<commands::ActiveMQDestination*>(
-                amqDestination->cloneDataStructure()) );
+        consumerInfo->setDestination( amqDestination->cloneDataStructure() );
 
         return consumerInfo;
 
@@ -652,7 +650,7 @@
             // Cast the destination to an OpenWire destination, so we can
             // get all the goodies.
             const commands::ActiveMQDestination* amqDestination =
-                dynamic_cast<const commands::ActiveMQDestination*>(destination);
+                dynamic_cast<const commands::ActiveMQDestination*>( destination );
             if( amqDestination == NULL ) {
                 throw ConnectorException( __FILE__, __LINE__,
                     "Destination was not created by this OpenWireConnector" );
@@ -660,8 +658,7 @@
 
             // Get any options specified in the destination and apply them to the
             // ProducerInfo object.
-            producerInfo->setDestination( dynamic_cast<commands::ActiveMQDestination*>(
-                amqDestination->cloneDataStructure()) );
+            producerInfo->setDestination( amqDestination->cloneDataStructure() );
             const ActiveMQProperties& options = amqDestination->getOptions();
             producerInfo->setDispatchAsync( Boolean::parseBoolean(
                 options.getProperty( "producer.dispatchAsync", "false" )) );
@@ -809,16 +806,14 @@
         // flag.  Not adding a message ID will cause an NPE at the broker.
         commands::MessageId* id = new commands::MessageId();
         id->setProducerId(
-            dynamic_cast<commands::ProducerId*>(
-                producer->getProducerInfo()->getProducerId()->cloneDataStructure() ) );
+            producer->getProducerInfo()->getProducerId()->cloneDataStructure() );
 
         id->setProducerSequenceId( producerSequenceIds.getNextSequenceId() );
 
         amqMessage->setMessageId( id );
 
         amqMessage->setProducerId(
-            dynamic_cast<commands::ProducerId*>(
-                producer->getProducerInfo()->getProducerId()->cloneDataStructure() ) );
+            producer->getProducerInfo()->getProducerId()->cloneDataStructure() );
 
         if( session->getAckMode() == cms::Session::SESSION_TRANSACTED ) {
 
@@ -834,9 +829,8 @@
             }
 
             amqMessage->setTransactionId(
-                dynamic_cast<commands::TransactionId*>(
-                    transactionInfo->getTransactionInfo()->
-                        getTransactionId()->cloneDataStructure() ) );
+                transactionInfo->getTransactionInfo()->
+                    getTransactionId()->cloneDataStructure() );
         }
 
         // Send the message to the broker.
@@ -913,18 +907,10 @@
         commands::MessageAck ack;
         ack.setAckType( (int)ackType );
         ack.setConsumerId(
-            dynamic_cast<commands::ConsumerId*>(
-                consumerInfo->getConsumerInfo()->
-                    getConsumerId()->cloneDataStructure() ) );
-        ack.setDestination(
-            dynamic_cast<commands::ActiveMQDestination*>(
-                amqMessage->getDestination()->cloneDataStructure() ) );
-        ack.setFirstMessageId(
-            dynamic_cast<commands::MessageId*>(
-                amqMessage->getMessageId()->cloneDataStructure() ) );
-        ack.setLastMessageId(
-            dynamic_cast<commands::MessageId*>(
-                amqMessage->getMessageId()->cloneDataStructure() ) );
+            consumerInfo->getConsumerInfo()->getConsumerId()->cloneDataStructure() );
+        ack.setDestination( amqMessage->getDestination()->cloneDataStructure() );
+        ack.setFirstMessageId( amqMessage->getMessageId()->cloneDataStructure() );
+        ack.setLastMessageId( amqMessage->getMessageId()->cloneDataStructure() );
         ack.setMessageCount( 1 );
 
         if( session->getAckMode() == cms::Session::SESSION_TRANSACTED ) {
@@ -947,8 +933,7 @@
                     transactionInfo->getTransactionInfo()->getTransactionId() );
 
             commands::TransactionId* clonedTransactionId =
-                dynamic_cast<commands::TransactionId*>(
-                    transactionId->cloneDataStructure() );
+                transactionId->cloneDataStructure();
 
             ack.setTransactionId( clonedTransactionId );
         }
@@ -988,9 +973,7 @@
         // Prepare and send the Transaction command
         commands::TransactionInfo* info = new commands::TransactionInfo();
 
-        info->setConnectionId(
-            dynamic_cast<commands::ConnectionId*>(
-                connectionInfo.getConnectionId()->cloneDataStructure() ) );
+        info->setConnectionId( connectionInfo.getConnectionId()->cloneDataStructure() );
         info->setTransactionId( createLocalTransactionId() );
         info->setType( (int)TRANSACTION_STATE_BEGIN );
 
@@ -1149,10 +1132,9 @@
         enforceConnected();
 
         rsi = new commands::RemoveSubscriptionInfo();
-        rsi->setConnectionId( dynamic_cast<commands::ConnectionId*>(
-            connectionInfo.getConnectionId()->cloneDataStructure()) );
-        rsi->setSubcriptionName(name);
-        rsi->setClientId(connectionInfo.getClientId());
+        rsi->setConnectionId( connectionInfo.getConnectionId()->cloneDataStructure() );
+        rsi->setSubcriptionName( name );
+        rsi->setClientId( connectionInfo.getClientId() );
 
         // Send the message to the broker.
         Response* response = syncRequest(rsi);
@@ -1189,12 +1171,12 @@
         commands::DataStructure* dataStructure = NULL;
 
         commands::ActiveMQTempDestination* tempDestination =
-            dynamic_cast<commands::ActiveMQTempDestination*>(resource);
+            dynamic_cast<commands::ActiveMQTempDestination*>( resource );
 
         if( typeid( *resource ) == typeid( OpenWireConsumerInfo ) ) {
 
             OpenWireConsumerInfo* consumer =
-                dynamic_cast<OpenWireConsumerInfo*>(resource);
+                dynamic_cast<OpenWireConsumerInfo*>( resource );
 
             // Remove this consumer from the consumer info map
             synchronized( &consumerInfoMap ) {
@@ -1363,13 +1345,16 @@
 {
     try
     {
-        Response* response = transport->request(command);
+        Response* response = transport->request( command );
 
-        commands::ExceptionResponse* exceptionResponse = dynamic_cast<commands::ExceptionResponse*>(response);
+        commands::ExceptionResponse* exceptionResponse =
+            dynamic_cast<commands::ExceptionResponse*>( response );
         if( exceptionResponse != NULL )
         {
             // Create an exception to hold the error information.
-            commands::BrokerError* brokerError = dynamic_cast<commands::BrokerError*>(exceptionResponse->getException());
+            commands::BrokerError* brokerError =
+                dynamic_cast<commands::BrokerError*>(
+                        exceptionResponse->getException() );
             BrokerException exception( __FILE__, __LINE__, brokerError );
 
             // Free the response command.
@@ -1410,12 +1395,9 @@
 
         commands::DestinationInfo command;
         command.setConnectionId(
-            dynamic_cast<commands::ConnectionId*>(
-                connectionInfo.getConnectionId()->cloneDataStructure() ) );
+            connectionInfo.getConnectionId()->cloneDataStructure() );
         command.setOperationType( 0 ); // 0 is add
-        command.setDestination(
-            dynamic_cast<commands::ActiveMQDestination*>(
-                tempDestination->cloneDataStructure() ) );
+        command.setDestination( tempDestination->cloneDataStructure() );
 
         // Send the message to the broker.
         Response* response = syncRequest(&command);
@@ -1439,12 +1421,10 @@
 
         commands::DestinationInfo command;
         command.setConnectionId(
-            dynamic_cast<commands::ConnectionId*>(
-                connectionInfo.getConnectionId()->cloneDataStructure() ) );
+            connectionInfo.getConnectionId()->cloneDataStructure() );
         command.setOperationType( 1 ); // 1 is remove
         command.setDestination(
-            dynamic_cast<commands::ActiveMQDestination*>(
-                tempDestination->cloneDataStructure() ) );
+            tempDestination->cloneDataStructure() );
 
         // Send the message to the broker.
         Response* response = syncRequest(&command);
@@ -1475,9 +1455,7 @@
 
     commands::LocalTransactionId* id = new commands::LocalTransactionId();
 
-    id->setConnectionId(
-        dynamic_cast<commands::ConnectionId*>(
-            connectionInfo.getConnectionId()->cloneDataStructure() ) );
+    id->setConnectionId( connectionInfo.getConnectionId()->cloneDataStructure() );
     id->setValue( transactionIds.getNextSequenceId() );
 
     return id;

Modified: activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ActiveMQBytesMessage.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ActiveMQBytesMessage.h?rev=585591&r1=585590&r2=585591&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ActiveMQBytesMessage.h (original)
+++ activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ActiveMQBytesMessage.h Wed Oct 17 10:35:05 2007
@@ -56,7 +56,7 @@
          * caller now owns, this will be an exact copy of this one
          * @returns new copy of this object.
          */
-        virtual DataStructure* cloneDataStructure() const {
+        virtual ActiveMQBytesMessage* cloneDataStructure() const {
             ActiveMQBytesMessage* message = new ActiveMQBytesMessage();
             message->copyDataStructure( this );
             return message;

Modified: activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ActiveMQDestination.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ActiveMQDestination.h?rev=585591&r1=585590&r2=585591&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ActiveMQDestination.h (original)
+++ activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ActiveMQDestination.h Wed Oct 17 10:35:05 2007
@@ -101,6 +101,15 @@
         virtual ~ActiveMQDestination() {}
 
         /**
+         * Clone this object and return a new instance that the
+         * caller now owns, this will be an exact copy of this one
+         * @returns new copy of this object.
+         */
+        virtual ActiveMQDestination* cloneDataStructure() const {
+            return NULL;
+        }
+
+        /**
          * Copy the contents of the passed object into this objects
          * members, overwriting any existing data.
          * @return src - Source Object

Modified: activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ActiveMQMapMessage.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ActiveMQMapMessage.h?rev=585591&r1=585590&r2=585591&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ActiveMQMapMessage.h (original)
+++ activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ActiveMQMapMessage.h Wed Oct 17 10:35:05 2007
@@ -63,7 +63,7 @@
          * caller now owns, this will be an exact copy of this one
          * @returns new copy of this object.
          */
-        virtual DataStructure* cloneDataStructure() const {
+        virtual ActiveMQMapMessage* cloneDataStructure() const {
             ActiveMQMapMessage* message = new ActiveMQMapMessage();
             message->copyDataStructure( this );
             return message;

Modified: activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ActiveMQMessage.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ActiveMQMessage.h?rev=585591&r1=585590&r2=585591&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ActiveMQMessage.h (original)
+++ activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ActiveMQMessage.h Wed Oct 17 10:35:05 2007
@@ -53,7 +53,7 @@
          * caller now owns, this will be an exact copy of this one
          * @returns new copy of this object.
          */
-        virtual DataStructure* cloneDataStructure() const {
+        virtual ActiveMQMessage* cloneDataStructure() const {
             ActiveMQMessage* message = new ActiveMQMessage();
             message->copyDataStructure( this );
             return message;

Modified: activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ActiveMQObjectMessage.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ActiveMQObjectMessage.h?rev=585591&r1=585590&r2=585591&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ActiveMQObjectMessage.h (original)
+++ activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ActiveMQObjectMessage.h Wed Oct 17 10:35:05 2007
@@ -50,7 +50,7 @@
          * caller now owns, this will be an exact copy of this one
          * @returns new copy of this object.
          */
-        virtual DataStructure* cloneDataStructure() const {
+        virtual ActiveMQObjectMessage* cloneDataStructure() const {
             ActiveMQObjectMessage* message = new ActiveMQObjectMessage();
             message->copyDataStructure( this );
             return message;

Modified: activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ActiveMQQueue.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ActiveMQQueue.h?rev=585591&r1=585590&r2=585591&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ActiveMQQueue.h (original)
+++ activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ActiveMQQueue.h Wed Oct 17 10:35:05 2007
@@ -53,7 +53,7 @@
          * caller now owns, this will be an exact copy of this one
          * @returns new copy of this object.
          */
-        virtual DataStructure* cloneDataStructure() const {
+        virtual ActiveMQQueue* cloneDataStructure() const {
             ActiveMQQueue* message = new ActiveMQQueue();
             message->copyDataStructure( this );
             return message;

Modified: activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ActiveMQStreamMessage.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ActiveMQStreamMessage.h?rev=585591&r1=585590&r2=585591&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ActiveMQStreamMessage.h (original)
+++ activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ActiveMQStreamMessage.h Wed Oct 17 10:35:05 2007
@@ -53,9 +53,9 @@
          * caller now owns, this will be an exact copy of this one
          * @returns new copy of this object.
          */
-        virtual DataStructure* cloneDataStructure() const { 
+        virtual ActiveMQStreamMessage* cloneDataStructure() const {
             ActiveMQStreamMessage* message = new ActiveMQStreamMessage();
-            message->copyDataStructure( this );            
+            message->copyDataStructure( this );
             return message;
         }
 
@@ -78,7 +78,7 @@
         virtual bool isExpired() const {
             return false;
         }
-      
+
     };
 
 }}}}

Modified: activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ActiveMQTempDestination.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ActiveMQTempDestination.h?rev=585591&r1=585590&r2=585591&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ActiveMQTempDestination.h (original)
+++ activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ActiveMQTempDestination.h Wed Oct 17 10:35:05 2007
@@ -59,6 +59,15 @@
         virtual unsigned char getDataStructureType() const;
 
         /**
+         * Clone this object and return a new instance that the
+         * caller now owns, this will be an exact copy of this one
+         * @returns new copy of this object.
+         */
+        virtual ActiveMQTempDestination* cloneDataStructure() const {
+            return NULL;
+        }
+
+        /**
          * Copy the contents of the passed object into this objects
          * members, overwriting any existing data.
          * @return src - Source Object

Modified: activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ActiveMQTempQueue.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ActiveMQTempQueue.h?rev=585591&r1=585590&r2=585591&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ActiveMQTempQueue.h (original)
+++ activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ActiveMQTempQueue.h Wed Oct 17 10:35:05 2007
@@ -56,7 +56,7 @@
          * caller now owns, this will be an exact copy of this one
          * @returns new copy of this object.
          */
-        virtual DataStructure* cloneDataStructure() const {
+        virtual ActiveMQTempQueue* cloneDataStructure() const {
             ActiveMQTempQueue* message = new ActiveMQTempQueue();
             message->copyDataStructure( this );
             return message;

Modified: activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ActiveMQTempTopic.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ActiveMQTempTopic.h?rev=585591&r1=585590&r2=585591&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ActiveMQTempTopic.h (original)
+++ activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ActiveMQTempTopic.h Wed Oct 17 10:35:05 2007
@@ -53,7 +53,7 @@
          * caller now owns, this will be an exact copy of this one
          * @returns new copy of this object.
          */
-        virtual DataStructure* cloneDataStructure() const {
+        virtual ActiveMQTempTopic* cloneDataStructure() const {
             ActiveMQTempTopic* message = new ActiveMQTempTopic();
             message->copyDataStructure( this );
             return message;

Modified: activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ActiveMQTextMessage.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ActiveMQTextMessage.h?rev=585591&r1=585590&r2=585591&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ActiveMQTextMessage.h (original)
+++ activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ActiveMQTextMessage.h Wed Oct 17 10:35:05 2007
@@ -52,7 +52,7 @@
          * caller now owns, this will be an exact copy of this one
          * @returns new copy of this object.
          */
-        virtual DataStructure* cloneDataStructure() const {
+        virtual ActiveMQTextMessage* cloneDataStructure() const {
             ActiveMQTextMessage* message = new ActiveMQTextMessage();
             message->copyDataStructure( this );
             return message;

Modified: activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ActiveMQTopic.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ActiveMQTopic.h?rev=585591&r1=585590&r2=585591&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ActiveMQTopic.h (original)
+++ activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ActiveMQTopic.h Wed Oct 17 10:35:05 2007
@@ -53,7 +53,7 @@
          * caller now owns, this will be an exact copy of this one
          * @returns new copy of this object.
          */
-        virtual DataStructure* cloneDataStructure() const {
+        virtual ActiveMQTopic* cloneDataStructure() const {
             ActiveMQTopic* message = new ActiveMQTopic();
             message->copyDataStructure( this );
             return message;

Modified: activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/BrokerId.cpp
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/BrokerId.cpp?rev=585591&r1=585590&r2=585591&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/BrokerId.cpp (original)
+++ activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/BrokerId.cpp Wed Oct 17 10:35:05 2007
@@ -46,7 +46,7 @@
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-DataStructure* BrokerId::cloneDataStructure() const {
+BrokerId* BrokerId::cloneDataStructure() const {
     BrokerId* brokerId = new BrokerId();
 
     // Copy the data from the base class or classes

Modified: activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/BrokerId.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/BrokerId.h?rev=585591&r1=585590&r2=585591&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/BrokerId.h (original)
+++ activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/BrokerId.h Wed Oct 17 10:35:05 2007
@@ -69,7 +69,7 @@
          * caller now owns, this will be an exact copy of this one
          * @returns new copy of this object.
          */
-        virtual DataStructure* cloneDataStructure() const;
+        virtual BrokerId* cloneDataStructure() const;
 
         /**
          * Copy the contents of the passed object into this object's

Modified: activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/BrokerInfo.cpp
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/BrokerInfo.cpp?rev=585591&r1=585590&r2=585591&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/BrokerInfo.cpp (original)
+++ activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/BrokerInfo.cpp Wed Oct 17 10:35:05 2007
@@ -58,7 +58,7 @@
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-DataStructure* BrokerInfo::cloneDataStructure() const {
+BrokerInfo* BrokerInfo::cloneDataStructure() const {
     BrokerInfo* brokerInfo = new BrokerInfo();
 
     // Copy the data from the base class or classes

Modified: activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/BrokerInfo.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/BrokerInfo.h?rev=585591&r1=585590&r2=585591&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/BrokerInfo.h (original)
+++ activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/BrokerInfo.h Wed Oct 17 10:35:05 2007
@@ -80,7 +80,7 @@
          * caller now owns, this will be an exact copy of this one
          * @returns new copy of this object.
          */
-        virtual DataStructure* cloneDataStructure() const;
+        virtual BrokerInfo* cloneDataStructure() const;
 
         /**
          * Copy the contents of the passed object into this object's

Modified: activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ConnectionControl.cpp
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ConnectionControl.cpp?rev=585591&r1=585590&r2=585591&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ConnectionControl.cpp (original)
+++ activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ConnectionControl.cpp Wed Oct 17 10:35:05 2007
@@ -50,7 +50,7 @@
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-DataStructure* ConnectionControl::cloneDataStructure() const {
+ConnectionControl* ConnectionControl::cloneDataStructure() const {
     ConnectionControl* connectionControl = new ConnectionControl();
 
     // Copy the data from the base class or classes

Modified: activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ConnectionControl.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ConnectionControl.h?rev=585591&r1=585590&r2=585591&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ConnectionControl.h (original)
+++ activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ConnectionControl.h Wed Oct 17 10:35:05 2007
@@ -73,7 +73,7 @@
          * caller now owns, this will be an exact copy of this one
          * @returns new copy of this object.
          */
-        virtual DataStructure* cloneDataStructure() const;
+        virtual ConnectionControl* cloneDataStructure() const;
 
         /**
          * Copy the contents of the passed object into this object's

Modified: activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ConnectionError.cpp
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ConnectionError.cpp?rev=585591&r1=585590&r2=585591&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ConnectionError.cpp (original)
+++ activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ConnectionError.cpp Wed Oct 17 10:35:05 2007
@@ -49,7 +49,7 @@
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-DataStructure* ConnectionError::cloneDataStructure() const {
+ConnectionError* ConnectionError::cloneDataStructure() const {
     ConnectionError* connectionError = new ConnectionError();
 
     // Copy the data from the base class or classes

Modified: activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ConnectionError.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ConnectionError.h?rev=585591&r1=585590&r2=585591&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ConnectionError.h (original)
+++ activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ConnectionError.h Wed Oct 17 10:35:05 2007
@@ -72,7 +72,7 @@
          * caller now owns, this will be an exact copy of this one
          * @returns new copy of this object.
          */
-        virtual DataStructure* cloneDataStructure() const;
+        virtual ConnectionError* cloneDataStructure() const;
 
         /**
          * Copy the contents of the passed object into this object's

Modified: activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ConnectionId.cpp
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ConnectionId.cpp?rev=585591&r1=585590&r2=585591&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ConnectionId.cpp (original)
+++ activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ConnectionId.cpp Wed Oct 17 10:35:05 2007
@@ -46,7 +46,7 @@
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-DataStructure* ConnectionId::cloneDataStructure() const {
+ConnectionId* ConnectionId::cloneDataStructure() const {
     ConnectionId* connectionId = new ConnectionId();
 
     // Copy the data from the base class or classes

Modified: activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ConnectionId.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ConnectionId.h?rev=585591&r1=585590&r2=585591&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ConnectionId.h (original)
+++ activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ConnectionId.h Wed Oct 17 10:35:05 2007
@@ -69,7 +69,7 @@
          * caller now owns, this will be an exact copy of this one
          * @returns new copy of this object.
          */
-        virtual DataStructure* cloneDataStructure() const;
+        virtual ConnectionId* cloneDataStructure() const;
 
         /**
          * Copy the contents of the passed object into this object's

Modified: activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ConnectionInfo.cpp
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ConnectionInfo.cpp?rev=585591&r1=585590&r2=585591&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ConnectionInfo.cpp (original)
+++ activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ConnectionInfo.cpp Wed Oct 17 10:35:05 2007
@@ -56,7 +56,7 @@
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-DataStructure* ConnectionInfo::cloneDataStructure() const {
+ConnectionInfo* ConnectionInfo::cloneDataStructure() const {
     ConnectionInfo* connectionInfo = new ConnectionInfo();
 
     // Copy the data from the base class or classes

Modified: activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ConnectionInfo.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ConnectionInfo.h?rev=585591&r1=585590&r2=585591&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ConnectionInfo.h (original)
+++ activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ConnectionInfo.h Wed Oct 17 10:35:05 2007
@@ -78,7 +78,7 @@
          * caller now owns, this will be an exact copy of this one
          * @returns new copy of this object.
          */
-        virtual DataStructure* cloneDataStructure() const;
+        virtual ConnectionInfo* cloneDataStructure() const;
 
         /**
          * Copy the contents of the passed object into this object's

Modified: activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ConsumerControl.cpp
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ConsumerControl.cpp?rev=585591&r1=585590&r2=585591&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ConsumerControl.cpp (original)
+++ activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ConsumerControl.cpp Wed Oct 17 10:35:05 2007
@@ -52,7 +52,7 @@
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-DataStructure* ConsumerControl::cloneDataStructure() const {
+ConsumerControl* ConsumerControl::cloneDataStructure() const {
     ConsumerControl* consumerControl = new ConsumerControl();
 
     // Copy the data from the base class or classes

Modified: activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ConsumerControl.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ConsumerControl.h?rev=585591&r1=585590&r2=585591&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ConsumerControl.h (original)
+++ activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ConsumerControl.h Wed Oct 17 10:35:05 2007
@@ -75,7 +75,7 @@
          * caller now owns, this will be an exact copy of this one
          * @returns new copy of this object.
          */
-        virtual DataStructure* cloneDataStructure() const;
+        virtual ConsumerControl* cloneDataStructure() const;
 
         /**
          * Copy the contents of the passed object into this object's

Modified: activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ConsumerId.cpp
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ConsumerId.cpp?rev=585591&r1=585590&r2=585591&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ConsumerId.cpp (original)
+++ activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ConsumerId.cpp Wed Oct 17 10:35:05 2007
@@ -48,7 +48,7 @@
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-DataStructure* ConsumerId::cloneDataStructure() const {
+ConsumerId* ConsumerId::cloneDataStructure() const {
     ConsumerId* consumerId = new ConsumerId();
 
     // Copy the data from the base class or classes

Modified: activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ConsumerId.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ConsumerId.h?rev=585591&r1=585590&r2=585591&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ConsumerId.h (original)
+++ activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ConsumerId.h Wed Oct 17 10:35:05 2007
@@ -71,7 +71,7 @@
          * caller now owns, this will be an exact copy of this one
          * @returns new copy of this object.
          */
-        virtual DataStructure* cloneDataStructure() const;
+        virtual ConsumerId* cloneDataStructure() const;
 
         /**
          * Copy the contents of the passed object into this object's

Modified: activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ConsumerInfo.cpp
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ConsumerInfo.cpp?rev=585591&r1=585590&r2=585591&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ConsumerInfo.cpp (original)
+++ activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ConsumerInfo.cpp Wed Oct 17 10:35:05 2007
@@ -67,7 +67,7 @@
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-DataStructure* ConsumerInfo::cloneDataStructure() const {
+ConsumerInfo* ConsumerInfo::cloneDataStructure() const {
     ConsumerInfo* consumerInfo = new ConsumerInfo();
 
     // Copy the data from the base class or classes

Modified: activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ConsumerInfo.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ConsumerInfo.h?rev=585591&r1=585590&r2=585591&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ConsumerInfo.h (original)
+++ activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ConsumerInfo.h Wed Oct 17 10:35:05 2007
@@ -89,7 +89,7 @@
          * caller now owns, this will be an exact copy of this one
          * @returns new copy of this object.
          */
-        virtual DataStructure* cloneDataStructure() const;
+        virtual ConsumerInfo* cloneDataStructure() const;
 
         /**
          * Copy the contents of the passed object into this object's

Modified: activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ControlCommand.cpp
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ControlCommand.cpp?rev=585591&r1=585590&r2=585591&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ControlCommand.cpp (original)
+++ activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ControlCommand.cpp Wed Oct 17 10:35:05 2007
@@ -46,7 +46,7 @@
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-DataStructure* ControlCommand::cloneDataStructure() const {
+ControlCommand* ControlCommand::cloneDataStructure() const {
     ControlCommand* controlCommand = new ControlCommand();
 
     // Copy the data from the base class or classes

Modified: activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ControlCommand.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ControlCommand.h?rev=585591&r1=585590&r2=585591&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ControlCommand.h (original)
+++ activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ControlCommand.h Wed Oct 17 10:35:05 2007
@@ -69,7 +69,7 @@
          * caller now owns, this will be an exact copy of this one
          * @returns new copy of this object.
          */
-        virtual DataStructure* cloneDataStructure() const;
+        virtual ControlCommand* cloneDataStructure() const;
 
         /**
          * Copy the contents of the passed object into this object's

Modified: activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/DataArrayResponse.cpp
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/DataArrayResponse.cpp?rev=585591&r1=585590&r2=585591&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/DataArrayResponse.cpp (original)
+++ activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/DataArrayResponse.cpp Wed Oct 17 10:35:05 2007
@@ -48,7 +48,7 @@
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-DataStructure* DataArrayResponse::cloneDataStructure() const {
+DataArrayResponse* DataArrayResponse::cloneDataStructure() const {
     DataArrayResponse* dataArrayResponse = new DataArrayResponse();
 
     // Copy the data from the base class or classes

Modified: activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/DataArrayResponse.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/DataArrayResponse.h?rev=585591&r1=585590&r2=585591&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/DataArrayResponse.h (original)
+++ activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/DataArrayResponse.h Wed Oct 17 10:35:05 2007
@@ -70,7 +70,7 @@
          * caller now owns, this will be an exact copy of this one
          * @returns new copy of this object.
          */
-        virtual DataStructure* cloneDataStructure() const;
+        virtual DataArrayResponse* cloneDataStructure() const;
 
         /**
          * Copy the contents of the passed object into this object's

Modified: activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/DataResponse.cpp
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/DataResponse.cpp?rev=585591&r1=585590&r2=585591&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/DataResponse.cpp (original)
+++ activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/DataResponse.cpp Wed Oct 17 10:35:05 2007
@@ -47,7 +47,7 @@
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-DataStructure* DataResponse::cloneDataStructure() const {
+DataResponse* DataResponse::cloneDataStructure() const {
     DataResponse* dataResponse = new DataResponse();
 
     // Copy the data from the base class or classes

Modified: activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/DataResponse.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/DataResponse.h?rev=585591&r1=585590&r2=585591&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/DataResponse.h (original)
+++ activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/DataResponse.h Wed Oct 17 10:35:05 2007
@@ -70,7 +70,7 @@
          * caller now owns, this will be an exact copy of this one
          * @returns new copy of this object.
          */
-        virtual DataStructure* cloneDataStructure() const;
+        virtual DataResponse* cloneDataStructure() const;
 
         /**
          * Copy the contents of the passed object into this object's

Modified: activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/DestinationInfo.cpp
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/DestinationInfo.cpp?rev=585591&r1=585590&r2=585591&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/DestinationInfo.cpp (original)
+++ activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/DestinationInfo.cpp Wed Oct 17 10:35:05 2007
@@ -54,7 +54,7 @@
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-DataStructure* DestinationInfo::cloneDataStructure() const {
+DestinationInfo* DestinationInfo::cloneDataStructure() const {
     DestinationInfo* destinationInfo = new DestinationInfo();
 
     // Copy the data from the base class or classes

Modified: activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/DestinationInfo.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/DestinationInfo.h?rev=585591&r1=585590&r2=585591&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/DestinationInfo.h (original)
+++ activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/DestinationInfo.h Wed Oct 17 10:35:05 2007
@@ -76,7 +76,7 @@
          * caller now owns, this will be an exact copy of this one
          * @returns new copy of this object.
          */
-        virtual DataStructure* cloneDataStructure() const;
+        virtual DestinationInfo* cloneDataStructure() const;
 
         /**
          * Copy the contents of the passed object into this object's

Modified: activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/DiscoveryEvent.cpp
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/DiscoveryEvent.cpp?rev=585591&r1=585590&r2=585591&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/DiscoveryEvent.cpp (original)
+++ activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/DiscoveryEvent.cpp Wed Oct 17 10:35:05 2007
@@ -47,7 +47,7 @@
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-DataStructure* DiscoveryEvent::cloneDataStructure() const {
+DiscoveryEvent* DiscoveryEvent::cloneDataStructure() const {
     DiscoveryEvent* discoveryEvent = new DiscoveryEvent();
 
     // Copy the data from the base class or classes

Modified: activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/DiscoveryEvent.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/DiscoveryEvent.h?rev=585591&r1=585590&r2=585591&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/DiscoveryEvent.h (original)
+++ activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/DiscoveryEvent.h Wed Oct 17 10:35:05 2007
@@ -70,7 +70,7 @@
          * caller now owns, this will be an exact copy of this one
          * @returns new copy of this object.
          */
-        virtual DataStructure* cloneDataStructure() const;
+        virtual DiscoveryEvent* cloneDataStructure() const;
 
         /**
          * Copy the contents of the passed object into this object's

Modified: activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ExceptionResponse.cpp
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ExceptionResponse.cpp?rev=585591&r1=585590&r2=585591&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ExceptionResponse.cpp (original)
+++ activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ExceptionResponse.cpp Wed Oct 17 10:35:05 2007
@@ -47,7 +47,7 @@
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-DataStructure* ExceptionResponse::cloneDataStructure() const {
+ExceptionResponse* ExceptionResponse::cloneDataStructure() const {
     ExceptionResponse* exceptionResponse = new ExceptionResponse();
 
     // Copy the data from the base class or classes

Modified: activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ExceptionResponse.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ExceptionResponse.h?rev=585591&r1=585590&r2=585591&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ExceptionResponse.h (original)
+++ activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/ExceptionResponse.h Wed Oct 17 10:35:05 2007
@@ -70,7 +70,7 @@
          * caller now owns, this will be an exact copy of this one
          * @returns new copy of this object.
          */
-        virtual DataStructure* cloneDataStructure() const;
+        virtual ExceptionResponse* cloneDataStructure() const;
 
         /**
          * Copy the contents of the passed object into this object's

Modified: activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/FlushCommand.cpp
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/FlushCommand.cpp?rev=585591&r1=585590&r2=585591&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/FlushCommand.cpp (original)
+++ activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/FlushCommand.cpp Wed Oct 17 10:35:05 2007
@@ -45,7 +45,7 @@
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-DataStructure* FlushCommand::cloneDataStructure() const {
+FlushCommand* FlushCommand::cloneDataStructure() const {
     FlushCommand* flushCommand = new FlushCommand();
 
     // Copy the data from the base class or classes

Modified: activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/FlushCommand.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/FlushCommand.h?rev=585591&r1=585590&r2=585591&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/FlushCommand.h (original)
+++ activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/FlushCommand.h Wed Oct 17 10:35:05 2007
@@ -68,7 +68,7 @@
          * caller now owns, this will be an exact copy of this one
          * @returns new copy of this object.
          */
-        virtual DataStructure* cloneDataStructure() const;
+        virtual FlushCommand* cloneDataStructure() const;
 
         /**
          * Copy the contents of the passed object into this object's

Modified: activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/IntegerResponse.cpp
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/IntegerResponse.cpp?rev=585591&r1=585590&r2=585591&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/IntegerResponse.cpp (original)
+++ activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/IntegerResponse.cpp Wed Oct 17 10:35:05 2007
@@ -46,7 +46,7 @@
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-DataStructure* IntegerResponse::cloneDataStructure() const {
+IntegerResponse* IntegerResponse::cloneDataStructure() const {
     IntegerResponse* integerResponse = new IntegerResponse();
 
     // Copy the data from the base class or classes

Modified: activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/IntegerResponse.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/IntegerResponse.h?rev=585591&r1=585590&r2=585591&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/IntegerResponse.h (original)
+++ activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/IntegerResponse.h Wed Oct 17 10:35:05 2007
@@ -69,7 +69,7 @@
          * caller now owns, this will be an exact copy of this one
          * @returns new copy of this object.
          */
-        virtual DataStructure* cloneDataStructure() const;
+        virtual IntegerResponse* cloneDataStructure() const;
 
         /**
          * Copy the contents of the passed object into this object's

Modified: activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/JournalQueueAck.cpp
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/JournalQueueAck.cpp?rev=585591&r1=585590&r2=585591&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/JournalQueueAck.cpp (original)
+++ activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/JournalQueueAck.cpp Wed Oct 17 10:35:05 2007
@@ -49,7 +49,7 @@
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-DataStructure* JournalQueueAck::cloneDataStructure() const {
+JournalQueueAck* JournalQueueAck::cloneDataStructure() const {
     JournalQueueAck* journalQueueAck = new JournalQueueAck();
 
     // Copy the data from the base class or classes

Modified: activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/JournalQueueAck.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/JournalQueueAck.h?rev=585591&r1=585590&r2=585591&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/JournalQueueAck.h (original)
+++ activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/JournalQueueAck.h Wed Oct 17 10:35:05 2007
@@ -72,7 +72,7 @@
          * caller now owns, this will be an exact copy of this one
          * @returns new copy of this object.
          */
-        virtual DataStructure* cloneDataStructure() const;
+        virtual JournalQueueAck* cloneDataStructure() const;
 
         /**
          * Copy the contents of the passed object into this object's

Modified: activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/JournalTopicAck.cpp
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/JournalTopicAck.cpp?rev=585591&r1=585590&r2=585591&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/JournalTopicAck.cpp (original)
+++ activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/JournalTopicAck.cpp Wed Oct 17 10:35:05 2007
@@ -54,7 +54,7 @@
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-DataStructure* JournalTopicAck::cloneDataStructure() const {
+JournalTopicAck* JournalTopicAck::cloneDataStructure() const {
     JournalTopicAck* journalTopicAck = new JournalTopicAck();
 
     // Copy the data from the base class or classes

Modified: activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/JournalTopicAck.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/JournalTopicAck.h?rev=585591&r1=585590&r2=585591&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/JournalTopicAck.h (original)
+++ activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/JournalTopicAck.h Wed Oct 17 10:35:05 2007
@@ -77,7 +77,7 @@
          * caller now owns, this will be an exact copy of this one
          * @returns new copy of this object.
          */
-        virtual DataStructure* cloneDataStructure() const;
+        virtual JournalTopicAck* cloneDataStructure() const;
 
         /**
          * Copy the contents of the passed object into this object's

Modified: activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/JournalTrace.cpp
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/JournalTrace.cpp?rev=585591&r1=585590&r2=585591&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/JournalTrace.cpp (original)
+++ activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/JournalTrace.cpp Wed Oct 17 10:35:05 2007
@@ -46,7 +46,7 @@
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-DataStructure* JournalTrace::cloneDataStructure() const {
+JournalTrace* JournalTrace::cloneDataStructure() const {
     JournalTrace* journalTrace = new JournalTrace();
 
     // Copy the data from the base class or classes

Modified: activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/JournalTrace.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/JournalTrace.h?rev=585591&r1=585590&r2=585591&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/JournalTrace.h (original)
+++ activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/JournalTrace.h Wed Oct 17 10:35:05 2007
@@ -69,7 +69,7 @@
          * caller now owns, this will be an exact copy of this one
          * @returns new copy of this object.
          */
-        virtual DataStructure* cloneDataStructure() const;
+        virtual JournalTrace* cloneDataStructure() const;
 
         /**
          * Copy the contents of the passed object into this object's

Modified: activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/JournalTransaction.cpp
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/JournalTransaction.cpp?rev=585591&r1=585590&r2=585591&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/JournalTransaction.cpp (original)
+++ activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/JournalTransaction.cpp Wed Oct 17 10:35:05 2007
@@ -49,7 +49,7 @@
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-DataStructure* JournalTransaction::cloneDataStructure() const {
+JournalTransaction* JournalTransaction::cloneDataStructure() const {
     JournalTransaction* journalTransaction = new JournalTransaction();
 
     // Copy the data from the base class or classes

Modified: activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/JournalTransaction.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/JournalTransaction.h?rev=585591&r1=585590&r2=585591&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/JournalTransaction.h (original)
+++ activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/JournalTransaction.h Wed Oct 17 10:35:05 2007
@@ -72,7 +72,7 @@
          * caller now owns, this will be an exact copy of this one
          * @returns new copy of this object.
          */
-        virtual DataStructure* cloneDataStructure() const;
+        virtual JournalTransaction* cloneDataStructure() const;
 
         /**
          * Copy the contents of the passed object into this object's

Modified: activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/KeepAliveInfo.cpp
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/KeepAliveInfo.cpp?rev=585591&r1=585590&r2=585591&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/KeepAliveInfo.cpp (original)
+++ activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/KeepAliveInfo.cpp Wed Oct 17 10:35:05 2007
@@ -45,7 +45,7 @@
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-DataStructure* KeepAliveInfo::cloneDataStructure() const {
+KeepAliveInfo* KeepAliveInfo::cloneDataStructure() const {
     KeepAliveInfo* keepAliveInfo = new KeepAliveInfo();
 
     // Copy the data from the base class or classes

Modified: activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/KeepAliveInfo.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/KeepAliveInfo.h?rev=585591&r1=585590&r2=585591&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/KeepAliveInfo.h (original)
+++ activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/KeepAliveInfo.h Wed Oct 17 10:35:05 2007
@@ -68,7 +68,7 @@
          * caller now owns, this will be an exact copy of this one
          * @returns new copy of this object.
          */
-        virtual DataStructure* cloneDataStructure() const;
+        virtual KeepAliveInfo* cloneDataStructure() const;
 
         /**
          * Copy the contents of the passed object into this object's

Modified: activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/LastPartialCommand.cpp
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/LastPartialCommand.cpp?rev=585591&r1=585590&r2=585591&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/LastPartialCommand.cpp (original)
+++ activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/LastPartialCommand.cpp Wed Oct 17 10:35:05 2007
@@ -45,7 +45,7 @@
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-DataStructure* LastPartialCommand::cloneDataStructure() const {
+LastPartialCommand* LastPartialCommand::cloneDataStructure() const {
     LastPartialCommand* lastPartialCommand = new LastPartialCommand();
 
     // Copy the data from the base class or classes

Modified: activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/LastPartialCommand.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/LastPartialCommand.h?rev=585591&r1=585590&r2=585591&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/LastPartialCommand.h (original)
+++ activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/LastPartialCommand.h Wed Oct 17 10:35:05 2007
@@ -68,7 +68,7 @@
          * caller now owns, this will be an exact copy of this one
          * @returns new copy of this object.
          */
-        virtual DataStructure* cloneDataStructure() const;
+        virtual LastPartialCommand* cloneDataStructure() const;
 
         /**
          * Copy the contents of the passed object into this object's

Modified: activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/LocalTransactionId.cpp
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/LocalTransactionId.cpp?rev=585591&r1=585590&r2=585591&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/LocalTransactionId.cpp (original)
+++ activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/LocalTransactionId.cpp Wed Oct 17 10:35:05 2007
@@ -48,7 +48,7 @@
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-DataStructure* LocalTransactionId::cloneDataStructure() const {
+LocalTransactionId* LocalTransactionId::cloneDataStructure() const {
     LocalTransactionId* localTransactionId = new LocalTransactionId();
 
     // Copy the data from the base class or classes

Modified: activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/LocalTransactionId.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/LocalTransactionId.h?rev=585591&r1=585590&r2=585591&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/LocalTransactionId.h (original)
+++ activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/LocalTransactionId.h Wed Oct 17 10:35:05 2007
@@ -71,7 +71,7 @@
          * caller now owns, this will be an exact copy of this one
          * @returns new copy of this object.
          */
-        virtual DataStructure* cloneDataStructure() const;
+        virtual LocalTransactionId* cloneDataStructure() const;
 
         /**
          * Copy the contents of the passed object into this object's

Modified: activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/Message.cpp
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/Message.cpp?rev=585591&r1=585590&r2=585591&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/Message.cpp (original)
+++ activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/Message.cpp Wed Oct 17 10:35:05 2007
@@ -80,7 +80,7 @@
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-DataStructure* Message::cloneDataStructure() const {
+Message* Message::cloneDataStructure() const {
     Message* message = new Message();
 
     // Copy the data from the base class or classes

Modified: activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/Message.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/Message.h?rev=585591&r1=585590&r2=585591&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/Message.h (original)
+++ activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/Message.h Wed Oct 17 10:35:05 2007
@@ -104,7 +104,7 @@
          * caller now owns, this will be an exact copy of this one
          * @returns new copy of this object.
          */
-        virtual DataStructure* cloneDataStructure() const;
+        virtual Message* cloneDataStructure() const;
 
         /**
          * Copy the contents of the passed object into this object's

Modified: activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/MessageAck.cpp
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/MessageAck.cpp?rev=585591&r1=585590&r2=585591&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/MessageAck.cpp (original)
+++ activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/MessageAck.cpp Wed Oct 17 10:35:05 2007
@@ -57,7 +57,7 @@
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-DataStructure* MessageAck::cloneDataStructure() const {
+MessageAck* MessageAck::cloneDataStructure() const {
     MessageAck* messageAck = new MessageAck();
 
     // Copy the data from the base class or classes

Modified: activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/MessageAck.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/MessageAck.h?rev=585591&r1=585590&r2=585591&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/MessageAck.h (original)
+++ activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/MessageAck.h Wed Oct 17 10:35:05 2007
@@ -80,7 +80,7 @@
          * caller now owns, this will be an exact copy of this one
          * @returns new copy of this object.
          */
-        virtual DataStructure* cloneDataStructure() const;
+        virtual MessageAck* cloneDataStructure() const;
 
         /**
          * Copy the contents of the passed object into this object's

Modified: activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/MessageDispatch.cpp
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/MessageDispatch.cpp?rev=585591&r1=585590&r2=585591&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/MessageDispatch.cpp (original)
+++ activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/MessageDispatch.cpp Wed Oct 17 10:35:05 2007
@@ -52,7 +52,7 @@
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-DataStructure* MessageDispatch::cloneDataStructure() const {
+MessageDispatch* MessageDispatch::cloneDataStructure() const {
     MessageDispatch* messageDispatch = new MessageDispatch();
 
     // Copy the data from the base class or classes

Modified: activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/MessageDispatch.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/MessageDispatch.h?rev=585591&r1=585590&r2=585591&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/MessageDispatch.h (original)
+++ activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/MessageDispatch.h Wed Oct 17 10:35:05 2007
@@ -75,7 +75,7 @@
          * caller now owns, this will be an exact copy of this one
          * @returns new copy of this object.
          */
-        virtual DataStructure* cloneDataStructure() const;
+        virtual MessageDispatch* cloneDataStructure() const;
 
         /**
          * Copy the contents of the passed object into this object's

Modified: activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/MessageDispatchNotification.cpp
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/MessageDispatchNotification.cpp?rev=585591&r1=585590&r2=585591&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/MessageDispatchNotification.cpp (original)
+++ activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/MessageDispatchNotification.cpp Wed Oct 17 10:35:05 2007
@@ -52,7 +52,7 @@
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-DataStructure* MessageDispatchNotification::cloneDataStructure() const {
+MessageDispatchNotification* MessageDispatchNotification::cloneDataStructure() const {
     MessageDispatchNotification* messageDispatchNotification = new MessageDispatchNotification();
 
     // Copy the data from the base class or classes

Modified: activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/MessageDispatchNotification.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/MessageDispatchNotification.h?rev=585591&r1=585590&r2=585591&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/MessageDispatchNotification.h (original)
+++ activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/MessageDispatchNotification.h Wed Oct 17 10:35:05 2007
@@ -75,7 +75,7 @@
          * caller now owns, this will be an exact copy of this one
          * @returns new copy of this object.
          */
-        virtual DataStructure* cloneDataStructure() const;
+        virtual MessageDispatchNotification* cloneDataStructure() const;
 
         /**
          * Copy the contents of the passed object into this object's

Modified: activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/MessageId.cpp
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/MessageId.cpp?rev=585591&r1=585590&r2=585591&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/MessageId.cpp (original)
+++ activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/MessageId.cpp Wed Oct 17 10:35:05 2007
@@ -49,7 +49,7 @@
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-DataStructure* MessageId::cloneDataStructure() const {
+MessageId* MessageId::cloneDataStructure() const {
     MessageId* messageId = new MessageId();
 
     // Copy the data from the base class or classes

Modified: activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/MessageId.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/MessageId.h?rev=585591&r1=585590&r2=585591&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/MessageId.h (original)
+++ activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/MessageId.h Wed Oct 17 10:35:05 2007
@@ -72,7 +72,7 @@
          * caller now owns, this will be an exact copy of this one
          * @returns new copy of this object.
          */
-        virtual DataStructure* cloneDataStructure() const;
+        virtual MessageId* cloneDataStructure() const;
 
         /**
          * Copy the contents of the passed object into this object's

Modified: activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/MessagePull.cpp
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/MessagePull.cpp?rev=585591&r1=585590&r2=585591&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/MessagePull.cpp (original)
+++ activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/MessagePull.cpp Wed Oct 17 10:35:05 2007
@@ -50,7 +50,7 @@
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-DataStructure* MessagePull::cloneDataStructure() const {
+MessagePull* MessagePull::cloneDataStructure() const {
     MessagePull* messagePull = new MessagePull();
 
     // Copy the data from the base class or classes

Modified: activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/MessagePull.h
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/MessagePull.h?rev=585591&r1=585590&r2=585591&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/MessagePull.h (original)
+++ activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/MessagePull.h Wed Oct 17 10:35:05 2007
@@ -73,7 +73,7 @@
          * caller now owns, this will be an exact copy of this one
          * @returns new copy of this object.
          */
-        virtual DataStructure* cloneDataStructure() const;
+        virtual MessagePull* cloneDataStructure() const;
 
         /**
          * Copy the contents of the passed object into this object's

Modified: activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/NetworkBridgeFilter.cpp
URL: http://svn.apache.org/viewvc/activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/NetworkBridgeFilter.cpp?rev=585591&r1=585590&r2=585591&view=diff
==============================================================================
--- activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/NetworkBridgeFilter.cpp (original)
+++ activemq/activemq-cpp/trunk/src/main/activemq/connector/openwire/commands/NetworkBridgeFilter.cpp Wed Oct 17 10:35:05 2007
@@ -48,7 +48,7 @@
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-DataStructure* NetworkBridgeFilter::cloneDataStructure() const {
+NetworkBridgeFilter* NetworkBridgeFilter::cloneDataStructure() const {
     NetworkBridgeFilter* networkBridgeFilter = new NetworkBridgeFilter();
 
     // Copy the data from the base class or classes