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

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

Modified: incubator/activemq/trunk/openwire-c/src/libopenwire/ow_commands_v1.h
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/openwire-c/src/libopenwire/ow_commands_v1.h?rev=383749&r1=383748&r2=383749&view=diff
==============================================================================
--- incubator/activemq/trunk/openwire-c/src/libopenwire/ow_commands_v1.h (original)
+++ incubator/activemq/trunk/openwire-c/src/libopenwire/ow_commands_v1.h Mon Mar  6 18:32:50 2006
@@ -39,101 +39,156 @@
 apr_status_t ow_bitmarshall(ow_bit_buffer *buffer, ow_DataStructure *object);
 apr_status_t ow_marshall(ow_byte_buffer *buffer, ow_DataStructure *object);
 
-typedef struct ow_MessageId {
+typedef struct ow_LocalTransactionId {
 
    ow_byte structType;
-   struct ow_ProducerId *producerId;
-   ow_long producerSequenceId;
-   ow_long brokerSequenceId;
+   ow_long value;
+   struct ow_ConnectionId *connectionId;
 
-} ow_MessageId;
-ow_MessageId *ow_MessageId_create(apr_pool_t *pool);
-ow_boolean ow_is_a_MessageId(ow_DataStructure *object);
+} ow_LocalTransactionId;
+ow_LocalTransactionId *ow_LocalTransactionId_create(apr_pool_t *pool);
+ow_boolean ow_is_a_LocalTransactionId(ow_DataStructure *object);
 
-typedef struct ow_BrokerInfo {
+typedef struct ow_IntegerResponse {
 
    ow_byte structType;
    ow_short commandId;
    ow_boolean responseRequired;
-   struct ow_BrokerId *brokerId;
-   ow_string *brokerURL;
-   ow_DataStructure_array *peerBrokerInfos;
-   ow_string *brokerName;
-   ow_boolean slaveBroker;
+   ow_short correlationId;
+   ow_int result;
 
-} ow_BrokerInfo;
-ow_BrokerInfo *ow_BrokerInfo_create(apr_pool_t *pool);
-ow_boolean ow_is_a_BrokerInfo(ow_DataStructure *object);
+} ow_IntegerResponse;
+ow_IntegerResponse *ow_IntegerResponse_create(apr_pool_t *pool);
+ow_boolean ow_is_a_IntegerResponse(ow_DataStructure *object);
 
-typedef struct ow_ActiveMQTempQueue {
+typedef struct ow_ActiveMQQueue {
 
    ow_byte structType;
    ow_string *physicalName;
 
-} ow_ActiveMQTempQueue;
-ow_ActiveMQTempQueue *ow_ActiveMQTempQueue_create(apr_pool_t *pool);
-ow_boolean ow_is_a_ActiveMQTempQueue(ow_DataStructure *object);
+} ow_ActiveMQQueue;
+ow_ActiveMQQueue *ow_ActiveMQQueue_create(apr_pool_t *pool);
+ow_boolean ow_is_a_ActiveMQQueue(ow_DataStructure *object);
 
-typedef struct ow_LocalTransactionId {
+typedef struct ow_TransactionId {
 
    ow_byte structType;
-   ow_long value;
-   struct ow_ConnectionId *connectionId;
 
-} ow_LocalTransactionId;
-ow_LocalTransactionId *ow_LocalTransactionId_create(apr_pool_t *pool);
-ow_boolean ow_is_a_LocalTransactionId(ow_DataStructure *object);
+} ow_TransactionId;
+ow_TransactionId *ow_TransactionId_create(apr_pool_t *pool);
+ow_boolean ow_is_a_TransactionId(ow_DataStructure *object);
 
-typedef struct ow_RemoveSubscriptionInfo {
+typedef struct ow_ActiveMQObjectMessage {
+
+   ow_byte structType;
+   ow_short commandId;
+   ow_boolean responseRequired;
+   struct ow_ProducerId *producerId;
+   struct ow_ActiveMQDestination *destination;
+   struct ow_TransactionId *transactionId;
+   struct ow_ActiveMQDestination *originalDestination;
+   struct ow_MessageId *messageId;
+   struct ow_TransactionId *originalTransactionId;
+   ow_string *groupID;
+   ow_int groupSequence;
+   ow_string *correlationId;
+   ow_boolean persistent;
+   ow_long expiration;
+   ow_byte priority;
+   struct ow_ActiveMQDestination *replyTo;
+   ow_long timestamp;
+   ow_string *type;
+   ow_byte_array *content;
+   ow_byte_array *marshalledProperties;
+   struct ow_DataStructure *dataStructure;
+   struct ow_ConsumerId *targetConsumerId;
+   ow_boolean compressed;
+   ow_int redeliveryCounter;
+   ow_DataStructure_array *brokerPath;
+   ow_long arrival;
+   ow_string *userID;
+   ow_boolean recievedByDFBridge;
+
+} ow_ActiveMQObjectMessage;
+ow_ActiveMQObjectMessage *ow_ActiveMQObjectMessage_create(apr_pool_t *pool);
+ow_boolean ow_is_a_ActiveMQObjectMessage(ow_DataStructure *object);
+
+typedef struct ow_ConnectionId {
+
+   ow_byte structType;
+   ow_string *value;
+
+} ow_ConnectionId;
+ow_ConnectionId *ow_ConnectionId_create(apr_pool_t *pool);
+ow_boolean ow_is_a_ConnectionId(ow_DataStructure *object);
+
+typedef struct ow_ConnectionInfo {
 
    ow_byte structType;
    ow_short commandId;
    ow_boolean responseRequired;
    struct ow_ConnectionId *connectionId;
-   ow_string *subcriptionName;
    ow_string *clientId;
+   ow_string *password;
+   ow_string *userName;
+   ow_DataStructure_array *brokerPath;
 
-} ow_RemoveSubscriptionInfo;
-ow_RemoveSubscriptionInfo *ow_RemoveSubscriptionInfo_create(apr_pool_t *pool);
-ow_boolean ow_is_a_RemoveSubscriptionInfo(ow_DataStructure *object);
+} ow_ConnectionInfo;
+ow_ConnectionInfo *ow_ConnectionInfo_create(apr_pool_t *pool);
+ow_boolean ow_is_a_ConnectionInfo(ow_DataStructure *object);
 
-typedef struct ow_IntegerResponse {
+typedef struct ow_ProducerInfo {
 
    ow_byte structType;
    ow_short commandId;
    ow_boolean responseRequired;
-   ow_short correlationId;
-   ow_int result;
+   struct ow_ProducerId *producerId;
+   struct ow_ActiveMQDestination *destination;
+   ow_DataStructure_array *brokerPath;
 
-} ow_IntegerResponse;
-ow_IntegerResponse *ow_IntegerResponse_create(apr_pool_t *pool);
-ow_boolean ow_is_a_IntegerResponse(ow_DataStructure *object);
+} ow_ProducerInfo;
+ow_ProducerInfo *ow_ProducerInfo_create(apr_pool_t *pool);
+ow_boolean ow_is_a_ProducerInfo(ow_DataStructure *object);
 
-typedef struct ow_ActiveMQQueue {
+typedef struct ow_MessageDispatchNotification {
 
    ow_byte structType;
-   ow_string *physicalName;
+   ow_short commandId;
+   ow_boolean responseRequired;
+   struct ow_ConsumerId *consumerId;
+   struct ow_ActiveMQDestination *destination;
+   ow_long deliverySequenceId;
+   struct ow_MessageId *messageId;
 
-} ow_ActiveMQQueue;
-ow_ActiveMQQueue *ow_ActiveMQQueue_create(apr_pool_t *pool);
-ow_boolean ow_is_a_ActiveMQQueue(ow_DataStructure *object);
+} ow_MessageDispatchNotification;
+ow_MessageDispatchNotification *ow_MessageDispatchNotification_create(apr_pool_t *pool);
+ow_boolean ow_is_a_MessageDispatchNotification(ow_DataStructure *object);
 
-typedef struct ow_DestinationInfo {
+typedef struct ow_SessionInfo {
+
+   ow_byte structType;
+   ow_short commandId;
+   ow_boolean responseRequired;
+   struct ow_SessionId *sessionId;
+
+} ow_SessionInfo;
+ow_SessionInfo *ow_SessionInfo_create(apr_pool_t *pool);
+ow_boolean ow_is_a_SessionInfo(ow_DataStructure *object);
+
+typedef struct ow_TransactionInfo {
 
    ow_byte structType;
    ow_short commandId;
    ow_boolean responseRequired;
    struct ow_ConnectionId *connectionId;
-   struct ow_ActiveMQDestination *destination;
-   ow_byte operationType;
-   ow_long timeout;
-   ow_DataStructure_array *brokerPath;
+   struct ow_TransactionId *transactionId;
+   ow_byte type;
 
-} ow_DestinationInfo;
-ow_DestinationInfo *ow_DestinationInfo_create(apr_pool_t *pool);
-ow_boolean ow_is_a_DestinationInfo(ow_DataStructure *object);
+} ow_TransactionInfo;
+ow_TransactionInfo *ow_TransactionInfo_create(apr_pool_t *pool);
+ow_boolean ow_is_a_TransactionInfo(ow_DataStructure *object);
 
-typedef struct ow_ActiveMQBytesMessage {
+typedef struct ow_ActiveMQStreamMessage {
 
    ow_byte structType;
    ow_short commandId;
@@ -164,31 +219,70 @@
    ow_string *userID;
    ow_boolean recievedByDFBridge;
 
-} ow_ActiveMQBytesMessage;
-ow_ActiveMQBytesMessage *ow_ActiveMQBytesMessage_create(apr_pool_t *pool);
-ow_boolean ow_is_a_ActiveMQBytesMessage(ow_DataStructure *object);
+} ow_ActiveMQStreamMessage;
+ow_ActiveMQStreamMessage *ow_ActiveMQStreamMessage_create(apr_pool_t *pool);
+ow_boolean ow_is_a_ActiveMQStreamMessage(ow_DataStructure *object);
 
-typedef struct ow_ShutdownInfo {
+typedef struct ow_MessageAck {
 
    ow_byte structType;
    ow_short commandId;
    ow_boolean responseRequired;
+   struct ow_ActiveMQDestination *destination;
+   struct ow_TransactionId *transactionId;
+   struct ow_ConsumerId *consumerId;
+   ow_byte ackType;
+   struct ow_MessageId *firstMessageId;
+   struct ow_MessageId *lastMessageId;
+   ow_int messageCount;
 
-} ow_ShutdownInfo;
-ow_ShutdownInfo *ow_ShutdownInfo_create(apr_pool_t *pool);
-ow_boolean ow_is_a_ShutdownInfo(ow_DataStructure *object);
+} ow_MessageAck;
+ow_MessageAck *ow_MessageAck_create(apr_pool_t *pool);
+ow_boolean ow_is_a_MessageAck(ow_DataStructure *object);
 
-typedef struct ow_DataResponse {
+typedef struct ow_ProducerId {
+
+   ow_byte structType;
+   ow_string *connectionId;
+   ow_long value;
+   ow_long sessionId;
+
+} ow_ProducerId;
+ow_ProducerId *ow_ProducerId_create(apr_pool_t *pool);
+ow_boolean ow_is_a_ProducerId(ow_DataStructure *object);
+
+typedef struct ow_MessageId {
+
+   ow_byte structType;
+   struct ow_ProducerId *producerId;
+   ow_long producerSequenceId;
+   ow_long brokerSequenceId;
+
+} ow_MessageId;
+ow_MessageId *ow_MessageId_create(apr_pool_t *pool);
+ow_boolean ow_is_a_MessageId(ow_DataStructure *object);
+
+typedef struct ow_ActiveMQTempQueue {
+
+   ow_byte structType;
+   ow_string *physicalName;
+
+} ow_ActiveMQTempQueue;
+ow_ActiveMQTempQueue *ow_ActiveMQTempQueue_create(apr_pool_t *pool);
+ow_boolean ow_is_a_ActiveMQTempQueue(ow_DataStructure *object);
+
+typedef struct ow_RemoveSubscriptionInfo {
 
    ow_byte structType;
    ow_short commandId;
    ow_boolean responseRequired;
-   ow_short correlationId;
-   struct ow_DataStructure *data;
+   struct ow_ConnectionId *connectionId;
+   ow_string *subcriptionName;
+   ow_string *clientId;
 
-} ow_DataResponse;
-ow_DataResponse *ow_DataResponse_create(apr_pool_t *pool);
-ow_boolean ow_is_a_DataResponse(ow_DataStructure *object);
+} ow_RemoveSubscriptionInfo;
+ow_RemoveSubscriptionInfo *ow_RemoveSubscriptionInfo_create(apr_pool_t *pool);
+ow_boolean ow_is_a_RemoveSubscriptionInfo(ow_DataStructure *object);
 
 typedef struct ow_SessionId {
 
@@ -222,29 +316,6 @@
 ow_JournalQueueAck *ow_JournalQueueAck_create(apr_pool_t *pool);
 ow_boolean ow_is_a_JournalQueueAck(ow_DataStructure *object);
 
-typedef struct ow_WireFormatInfo {
-
-   ow_byte structType;
-   ow_byte_array *magic;
-   ow_int version;
-   ow_boolean cacheEnabled;
-   ow_boolean stackTraceEnabled;
-   ow_boolean tcpNoDelayEnabled;
-   ow_boolean prefixPacketSize;
-   ow_boolean tightEncodingEnabled;
-
-} ow_WireFormatInfo;
-ow_WireFormatInfo *ow_WireFormatInfo_create(apr_pool_t *pool);
-ow_boolean ow_is_a_WireFormatInfo(ow_DataStructure *object);
-
-typedef struct ow_TransactionId {
-
-   ow_byte structType;
-
-} ow_TransactionId;
-ow_TransactionId *ow_TransactionId_create(apr_pool_t *pool);
-ow_boolean ow_is_a_TransactionId(ow_DataStructure *object);
-
 typedef struct ow_Response {
 
    ow_byte structType;
@@ -268,7 +339,63 @@
 ow_ConnectionError *ow_ConnectionError_create(apr_pool_t *pool);
 ow_boolean ow_is_a_ConnectionError(ow_DataStructure *object);
 
-typedef struct ow_ActiveMQObjectMessage {
+typedef struct ow_ConsumerInfo {
+
+   ow_byte structType;
+   ow_short commandId;
+   ow_boolean responseRequired;
+   struct ow_ConsumerId *consumerId;
+   ow_boolean browser;
+   struct ow_ActiveMQDestination *destination;
+   ow_int prefetchSize;
+   ow_int maximumPendingMessageLimit;
+   ow_boolean dispatchAsync;
+   ow_string *selector;
+   ow_string *subcriptionName;
+   ow_boolean noLocal;
+   ow_boolean exclusive;
+   ow_boolean retroactive;
+   ow_byte priority;
+   ow_DataStructure_array *brokerPath;
+   struct ow_BooleanExpression *additionalPredicate;
+   ow_boolean networkSubscription;
+
+} ow_ConsumerInfo;
+ow_ConsumerInfo *ow_ConsumerInfo_create(apr_pool_t *pool);
+ow_boolean ow_is_a_ConsumerInfo(ow_DataStructure *object);
+
+typedef struct ow_XATransactionId {
+
+   ow_byte structType;
+   ow_int formatId;
+   ow_byte_array *globalTransactionId;
+   ow_byte_array *branchQualifier;
+
+} ow_XATransactionId;
+ow_XATransactionId *ow_XATransactionId_create(apr_pool_t *pool);
+ow_boolean ow_is_a_XATransactionId(ow_DataStructure *object);
+
+typedef struct ow_JournalTrace {
+
+   ow_byte structType;
+   ow_string *message;
+
+} ow_JournalTrace;
+ow_JournalTrace *ow_JournalTrace_create(apr_pool_t *pool);
+ow_boolean ow_is_a_JournalTrace(ow_DataStructure *object);
+
+typedef struct ow_ConsumerId {
+
+   ow_byte structType;
+   ow_string *connectionId;
+   ow_long sessionId;
+   ow_long value;
+
+} ow_ConsumerId;
+ow_ConsumerId *ow_ConsumerId_create(apr_pool_t *pool);
+ow_boolean ow_is_a_ConsumerId(ow_DataStructure *object);
+
+typedef struct ow_ActiveMQTextMessage {
 
    ow_byte structType;
    ow_short commandId;
@@ -299,33 +426,99 @@
    ow_string *userID;
    ow_boolean recievedByDFBridge;
 
-} ow_ActiveMQObjectMessage;
-ow_ActiveMQObjectMessage *ow_ActiveMQObjectMessage_create(apr_pool_t *pool);
-ow_boolean ow_is_a_ActiveMQObjectMessage(ow_DataStructure *object);
+} ow_ActiveMQTextMessage;
+ow_ActiveMQTextMessage *ow_ActiveMQTextMessage_create(apr_pool_t *pool);
+ow_boolean ow_is_a_ActiveMQTextMessage(ow_DataStructure *object);
 
-typedef struct ow_ConsumerInfo {
+typedef struct ow_SubscriptionInfo {
 
    ow_byte structType;
-   ow_short commandId;
-   ow_boolean responseRequired;
-   struct ow_ConsumerId *consumerId;
-   ow_boolean browser;
+   ow_string *clientId;
    struct ow_ActiveMQDestination *destination;
-   ow_int prefetchSize;
-   ow_int maximumPendingMessageLimit;
-   ow_boolean dispatchAsync;
    ow_string *selector;
    ow_string *subcriptionName;
-   ow_boolean noLocal;
-   ow_boolean exclusive;
-   ow_boolean retroactive;
+
+} ow_SubscriptionInfo;
+ow_SubscriptionInfo *ow_SubscriptionInfo_create(apr_pool_t *pool);
+ow_boolean ow_is_a_SubscriptionInfo(ow_DataStructure *object);
+
+typedef struct ow_JournalTransaction {
+
+   ow_byte structType;
+   struct ow_TransactionId *transactionId;
+   ow_byte type;
+   ow_boolean wasPrepared;
+
+} ow_JournalTransaction;
+ow_JournalTransaction *ow_JournalTransaction_create(apr_pool_t *pool);
+ow_boolean ow_is_a_JournalTransaction(ow_DataStructure *object);
+
+typedef struct ow_ControlCommand {
+
+   ow_byte structType;
+   ow_short commandId;
+   ow_boolean responseRequired;
+   ow_string *command;
+
+} ow_ControlCommand;
+ow_ControlCommand *ow_ControlCommand_create(apr_pool_t *pool);
+ow_boolean ow_is_a_ControlCommand(ow_DataStructure *object);
+
+typedef struct ow_NetworkBridgeFilter {
+
+   ow_byte structType;
+   ow_int networkTTL;
+   struct ow_BrokerId *networkBrokerId;
+
+} ow_NetworkBridgeFilter;
+ow_NetworkBridgeFilter *ow_NetworkBridgeFilter_create(apr_pool_t *pool);
+ow_boolean ow_is_a_NetworkBridgeFilter(ow_DataStructure *object);
+
+typedef struct ow_ActiveMQBytesMessage {
+
+   ow_byte structType;
+   ow_short commandId;
+   ow_boolean responseRequired;
+   struct ow_ProducerId *producerId;
+   struct ow_ActiveMQDestination *destination;
+   struct ow_TransactionId *transactionId;
+   struct ow_ActiveMQDestination *originalDestination;
+   struct ow_MessageId *messageId;
+   struct ow_TransactionId *originalTransactionId;
+   ow_string *groupID;
+   ow_int groupSequence;
+   ow_string *correlationId;
+   ow_boolean persistent;
+   ow_long expiration;
    ow_byte priority;
+   struct ow_ActiveMQDestination *replyTo;
+   ow_long timestamp;
+   ow_string *type;
+   ow_byte_array *content;
+   ow_byte_array *marshalledProperties;
+   struct ow_DataStructure *dataStructure;
+   struct ow_ConsumerId *targetConsumerId;
+   ow_boolean compressed;
+   ow_int redeliveryCounter;
    ow_DataStructure_array *brokerPath;
-   ow_boolean networkSubscription;
+   ow_long arrival;
+   ow_string *userID;
+   ow_boolean recievedByDFBridge;
 
-} ow_ConsumerInfo;
-ow_ConsumerInfo *ow_ConsumerInfo_create(apr_pool_t *pool);
-ow_boolean ow_is_a_ConsumerInfo(ow_DataStructure *object);
+} ow_ActiveMQBytesMessage;
+ow_ActiveMQBytesMessage *ow_ActiveMQBytesMessage_create(apr_pool_t *pool);
+ow_boolean ow_is_a_ActiveMQBytesMessage(ow_DataStructure *object);
+
+typedef struct ow_WireFormatInfo {
+
+   ow_byte structType;
+   ow_byte_array *magic;
+   ow_int version;
+   ow_byte_array *marshalledProperties;
+
+} ow_WireFormatInfo;
+ow_WireFormatInfo *ow_WireFormatInfo_create(apr_pool_t *pool);
+ow_boolean ow_is_a_WireFormatInfo(ow_DataStructure *object);
 
 typedef struct ow_ActiveMQTempTopic {
 
@@ -336,15 +529,6 @@
 ow_ActiveMQTempTopic *ow_ActiveMQTempTopic_create(apr_pool_t *pool);
 ow_boolean ow_is_a_ActiveMQTempTopic(ow_DataStructure *object);
 
-typedef struct ow_ConnectionId {
-
-   ow_byte structType;
-   ow_string *value;
-
-} ow_ConnectionId;
-ow_ConnectionId *ow_ConnectionId_create(apr_pool_t *pool);
-ow_boolean ow_is_a_ConnectionId(ow_DataStructure *object);
-
 typedef struct ow_DiscoveryEvent {
 
    ow_byte structType;
@@ -355,20 +539,84 @@
 ow_DiscoveryEvent *ow_DiscoveryEvent_create(apr_pool_t *pool);
 ow_boolean ow_is_a_DiscoveryEvent(ow_DataStructure *object);
 
-typedef struct ow_ConnectionInfo {
+typedef struct ow_ActiveMQTempDestination {
+
+   ow_byte structType;
+   ow_string *physicalName;
+
+} ow_ActiveMQTempDestination;
+ow_ActiveMQTempDestination *ow_ActiveMQTempDestination_create(apr_pool_t *pool);
+ow_boolean ow_is_a_ActiveMQTempDestination(ow_DataStructure *object);
+
+typedef struct ow_ActiveMQDestination {
+
+   ow_byte structType;
+   ow_string *physicalName;
+
+} ow_ActiveMQDestination;
+ow_ActiveMQDestination *ow_ActiveMQDestination_create(apr_pool_t *pool);
+ow_boolean ow_is_a_ActiveMQDestination(ow_DataStructure *object);
+
+typedef struct ow_ActiveMQTopic {
+
+   ow_byte structType;
+   ow_string *physicalName;
+
+} ow_ActiveMQTopic;
+ow_ActiveMQTopic *ow_ActiveMQTopic_create(apr_pool_t *pool);
+ow_boolean ow_is_a_ActiveMQTopic(ow_DataStructure *object);
+
+typedef struct ow_BrokerInfo {
+
+   ow_byte structType;
+   ow_short commandId;
+   ow_boolean responseRequired;
+   struct ow_BrokerId *brokerId;
+   ow_string *brokerURL;
+   ow_DataStructure_array *peerBrokerInfos;
+   ow_string *brokerName;
+   ow_boolean slaveBroker;
+
+} ow_BrokerInfo;
+ow_BrokerInfo *ow_BrokerInfo_create(apr_pool_t *pool);
+ow_boolean ow_is_a_BrokerInfo(ow_DataStructure *object);
+
+typedef struct ow_DestinationInfo {
+
+   ow_byte structType;
+   ow_short commandId;
+   ow_boolean responseRequired;
+   struct ow_ConnectionId *connectionId;
+   struct ow_ActiveMQDestination *destination;
+   ow_byte operationType;
+   ow_long timeout;
+   ow_DataStructure_array *brokerPath;
+
+} ow_DestinationInfo;
+ow_DestinationInfo *ow_DestinationInfo_create(apr_pool_t *pool);
+ow_boolean ow_is_a_DestinationInfo(ow_DataStructure *object);
+
+typedef struct ow_ShutdownInfo {
+
+   ow_byte structType;
+   ow_short commandId;
+   ow_boolean responseRequired;
+
+} ow_ShutdownInfo;
+ow_ShutdownInfo *ow_ShutdownInfo_create(apr_pool_t *pool);
+ow_boolean ow_is_a_ShutdownInfo(ow_DataStructure *object);
+
+typedef struct ow_DataResponse {
 
    ow_byte structType;
    ow_short commandId;
    ow_boolean responseRequired;
-   struct ow_ConnectionId *connectionId;
-   ow_string *clientId;
-   ow_string *password;
-   ow_string *userName;
-   ow_DataStructure_array *brokerPath;
+   ow_short correlationId;
+   struct ow_DataStructure *data;
 
-} ow_ConnectionInfo;
-ow_ConnectionInfo *ow_ConnectionInfo_create(apr_pool_t *pool);
-ow_boolean ow_is_a_ConnectionInfo(ow_DataStructure *object);
+} ow_DataResponse;
+ow_DataResponse *ow_DataResponse_create(apr_pool_t *pool);
+ow_boolean ow_is_a_DataResponse(ow_DataStructure *object);
 
 typedef struct ow_KeepAliveInfo {
 
@@ -423,26 +671,6 @@
 ow_BaseCommand *ow_BaseCommand_create(apr_pool_t *pool);
 ow_boolean ow_is_a_BaseCommand(ow_DataStructure *object);
 
-typedef struct ow_XATransactionId {
-
-   ow_byte structType;
-   ow_int formatId;
-   ow_byte_array *globalTransactionId;
-   ow_byte_array *branchQualifier;
-
-} ow_XATransactionId;
-ow_XATransactionId *ow_XATransactionId_create(apr_pool_t *pool);
-ow_boolean ow_is_a_XATransactionId(ow_DataStructure *object);
-
-typedef struct ow_JournalTrace {
-
-   ow_byte structType;
-   ow_string *message;
-
-} ow_JournalTrace;
-ow_JournalTrace *ow_JournalTrace_create(apr_pool_t *pool);
-ow_boolean ow_is_a_JournalTrace(ow_DataStructure *object);
-
 typedef struct ow_FlushCommand {
 
    ow_byte structType;
@@ -453,26 +681,6 @@
 ow_FlushCommand *ow_FlushCommand_create(apr_pool_t *pool);
 ow_boolean ow_is_a_FlushCommand(ow_DataStructure *object);
 
-typedef struct ow_ActiveMQTempDestination {
-
-   ow_byte structType;
-   ow_string *physicalName;
-
-} ow_ActiveMQTempDestination;
-ow_ActiveMQTempDestination *ow_ActiveMQTempDestination_create(apr_pool_t *pool);
-ow_boolean ow_is_a_ActiveMQTempDestination(ow_DataStructure *object);
-
-typedef struct ow_ConsumerId {
-
-   ow_byte structType;
-   ow_string *connectionId;
-   ow_long sessionId;
-   ow_long value;
-
-} ow_ConsumerId;
-ow_ConsumerId *ow_ConsumerId_create(apr_pool_t *pool);
-ow_boolean ow_is_a_ConsumerId(ow_DataStructure *object);
-
 typedef struct ow_JournalTopicAck {
 
    ow_byte structType;
@@ -487,41 +695,6 @@
 ow_JournalTopicAck *ow_JournalTopicAck_create(apr_pool_t *pool);
 ow_boolean ow_is_a_JournalTopicAck(ow_DataStructure *object);
 
-typedef struct ow_ActiveMQTextMessage {
-
-   ow_byte structType;
-   ow_short commandId;
-   ow_boolean responseRequired;
-   struct ow_ProducerId *producerId;
-   struct ow_ActiveMQDestination *destination;
-   struct ow_TransactionId *transactionId;
-   struct ow_ActiveMQDestination *originalDestination;
-   struct ow_MessageId *messageId;
-   struct ow_TransactionId *originalTransactionId;
-   ow_string *groupID;
-   ow_int groupSequence;
-   ow_string *correlationId;
-   ow_boolean persistent;
-   ow_long expiration;
-   ow_byte priority;
-   struct ow_ActiveMQDestination *replyTo;
-   ow_long timestamp;
-   ow_string *type;
-   ow_byte_array *content;
-   ow_byte_array *marshalledProperties;
-   struct ow_DataStructure *dataStructure;
-   struct ow_ConsumerId *targetConsumerId;
-   ow_boolean compressed;
-   ow_int redeliveryCounter;
-   ow_DataStructure_array *brokerPath;
-   ow_long arrival;
-   ow_string *userID;
-   ow_boolean recievedByDFBridge;
-
-} ow_ActiveMQTextMessage;
-ow_ActiveMQTextMessage *ow_ActiveMQTextMessage_create(apr_pool_t *pool);
-ow_boolean ow_is_a_ActiveMQTextMessage(ow_DataStructure *object);
-
 typedef struct ow_BrokerId {
 
    ow_byte structType;
@@ -545,31 +718,6 @@
 ow_MessageDispatch *ow_MessageDispatch_create(apr_pool_t *pool);
 ow_boolean ow_is_a_MessageDispatch(ow_DataStructure *object);
 
-typedef struct ow_ProducerInfo {
-
-   ow_byte structType;
-   ow_short commandId;
-   ow_boolean responseRequired;
-   struct ow_ProducerId *producerId;
-   struct ow_ActiveMQDestination *destination;
-   ow_DataStructure_array *brokerPath;
-
-} ow_ProducerInfo;
-ow_ProducerInfo *ow_ProducerInfo_create(apr_pool_t *pool);
-ow_boolean ow_is_a_ProducerInfo(ow_DataStructure *object);
-
-typedef struct ow_SubscriptionInfo {
-
-   ow_byte structType;
-   ow_string *clientId;
-   struct ow_ActiveMQDestination *destination;
-   ow_string *selector;
-   ow_string *subcriptionName;
-
-} ow_SubscriptionInfo;
-ow_SubscriptionInfo *ow_SubscriptionInfo_create(apr_pool_t *pool);
-ow_boolean ow_is_a_SubscriptionInfo(ow_DataStructure *object);
-
 typedef struct ow_ActiveMQMapMessage {
 
    ow_byte structType;
@@ -605,31 +753,6 @@
 ow_ActiveMQMapMessage *ow_ActiveMQMapMessage_create(apr_pool_t *pool);
 ow_boolean ow_is_a_ActiveMQMapMessage(ow_DataStructure *object);
 
-typedef struct ow_MessageDispatchNotification {
-
-   ow_byte structType;
-   ow_short commandId;
-   ow_boolean responseRequired;
-   struct ow_ConsumerId *consumerId;
-   struct ow_ActiveMQDestination *destination;
-   ow_long deliverySequenceId;
-   struct ow_MessageId *messageId;
-
-} ow_MessageDispatchNotification;
-ow_MessageDispatchNotification *ow_MessageDispatchNotification_create(apr_pool_t *pool);
-ow_boolean ow_is_a_MessageDispatchNotification(ow_DataStructure *object);
-
-typedef struct ow_SessionInfo {
-
-   ow_byte structType;
-   ow_short commandId;
-   ow_boolean responseRequired;
-   struct ow_SessionId *sessionId;
-
-} ow_SessionInfo;
-ow_SessionInfo *ow_SessionInfo_create(apr_pool_t *pool);
-ow_boolean ow_is_a_SessionInfo(ow_DataStructure *object);
-
 typedef struct ow_ActiveMQMessage {
 
    ow_byte structType;
@@ -665,111 +788,6 @@
 ow_ActiveMQMessage *ow_ActiveMQMessage_create(apr_pool_t *pool);
 ow_boolean ow_is_a_ActiveMQMessage(ow_DataStructure *object);
 
-typedef struct ow_TransactionInfo {
-
-   ow_byte structType;
-   ow_short commandId;
-   ow_boolean responseRequired;
-   struct ow_ConnectionId *connectionId;
-   struct ow_TransactionId *transactionId;
-   ow_byte type;
-
-} ow_TransactionInfo;
-ow_TransactionInfo *ow_TransactionInfo_create(apr_pool_t *pool);
-ow_boolean ow_is_a_TransactionInfo(ow_DataStructure *object);
-
-typedef struct ow_ActiveMQStreamMessage {
-
-   ow_byte structType;
-   ow_short commandId;
-   ow_boolean responseRequired;
-   struct ow_ProducerId *producerId;
-   struct ow_ActiveMQDestination *destination;
-   struct ow_TransactionId *transactionId;
-   struct ow_ActiveMQDestination *originalDestination;
-   struct ow_MessageId *messageId;
-   struct ow_TransactionId *originalTransactionId;
-   ow_string *groupID;
-   ow_int groupSequence;
-   ow_string *correlationId;
-   ow_boolean persistent;
-   ow_long expiration;
-   ow_byte priority;
-   struct ow_ActiveMQDestination *replyTo;
-   ow_long timestamp;
-   ow_string *type;
-   ow_byte_array *content;
-   ow_byte_array *marshalledProperties;
-   struct ow_DataStructure *dataStructure;
-   struct ow_ConsumerId *targetConsumerId;
-   ow_boolean compressed;
-   ow_int redeliveryCounter;
-   ow_DataStructure_array *brokerPath;
-   ow_long arrival;
-   ow_string *userID;
-   ow_boolean recievedByDFBridge;
-
-} ow_ActiveMQStreamMessage;
-ow_ActiveMQStreamMessage *ow_ActiveMQStreamMessage_create(apr_pool_t *pool);
-ow_boolean ow_is_a_ActiveMQStreamMessage(ow_DataStructure *object);
-
-typedef struct ow_ActiveMQDestination {
-
-   ow_byte structType;
-   ow_string *physicalName;
-
-} ow_ActiveMQDestination;
-ow_ActiveMQDestination *ow_ActiveMQDestination_create(apr_pool_t *pool);
-ow_boolean ow_is_a_ActiveMQDestination(ow_DataStructure *object);
-
-typedef struct ow_MessageAck {
-
-   ow_byte structType;
-   ow_short commandId;
-   ow_boolean responseRequired;
-   struct ow_ActiveMQDestination *destination;
-   struct ow_TransactionId *transactionId;
-   struct ow_ConsumerId *consumerId;
-   ow_byte ackType;
-   struct ow_MessageId *firstMessageId;
-   struct ow_MessageId *lastMessageId;
-   ow_int messageCount;
-
-} ow_MessageAck;
-ow_MessageAck *ow_MessageAck_create(apr_pool_t *pool);
-ow_boolean ow_is_a_MessageAck(ow_DataStructure *object);
-
-typedef struct ow_ProducerId {
-
-   ow_byte structType;
-   ow_string *connectionId;
-   ow_long value;
-   ow_long sessionId;
-
-} ow_ProducerId;
-ow_ProducerId *ow_ProducerId_create(apr_pool_t *pool);
-ow_boolean ow_is_a_ProducerId(ow_DataStructure *object);
-
-typedef struct ow_ActiveMQTopic {
-
-   ow_byte structType;
-   ow_string *physicalName;
-
-} ow_ActiveMQTopic;
-ow_ActiveMQTopic *ow_ActiveMQTopic_create(apr_pool_t *pool);
-ow_boolean ow_is_a_ActiveMQTopic(ow_DataStructure *object);
-
-typedef struct ow_JournalTransaction {
-
-   ow_byte structType;
-   struct ow_TransactionId *transactionId;
-   ow_byte type;
-   ow_boolean wasPrepared;
-
-} ow_JournalTransaction;
-ow_JournalTransaction *ow_JournalTransaction_create(apr_pool_t *pool);
-ow_boolean ow_is_a_JournalTransaction(ow_DataStructure *object);
-
 typedef struct ow_RemoveInfo {
 
    ow_byte structType;
@@ -780,17 +798,6 @@
 } ow_RemoveInfo;
 ow_RemoveInfo *ow_RemoveInfo_create(apr_pool_t *pool);
 ow_boolean ow_is_a_RemoveInfo(ow_DataStructure *object);
-
-typedef struct ow_ControlCommand {
-
-   ow_byte structType;
-   ow_short commandId;
-   ow_boolean responseRequired;
-   ow_string *command;
-
-} ow_ControlCommand;
-ow_ControlCommand *ow_ControlCommand_create(apr_pool_t *pool);
-ow_boolean ow_is_a_ControlCommand(ow_DataStructure *object);
 
 typedef struct ow_ExceptionResponse {
 

Modified: incubator/activemq/trunk/openwire-cpp/src/command/ActiveMQObjectMessage.hpp
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/openwire-cpp/src/command/ActiveMQObjectMessage.hpp?rev=383749&r1=383748&r2=383749&view=diff
==============================================================================
--- incubator/activemq/trunk/openwire-cpp/src/command/ActiveMQObjectMessage.hpp (original)
+++ incubator/activemq/trunk/openwire-cpp/src/command/ActiveMQObjectMessage.hpp Mon Mar  6 18:32:50 2006
@@ -1,71 +1 @@
-/*
-* Copyright 2006 The Apache Software Foundation or its licensors, as
-* applicable.
-*
-* Licensed under the Apache License, Version 2.0 (the "License");
-* you may not use this file except in compliance with the License.
-* You may obtain a copy of the License at
-*
-*     http://www.apache.org/licenses/LICENSE-2.0
-*
-* Unless required by applicable law or agreed to in writing, software
-* distributed under the License is distributed on an "AS IS" BASIS,
-* WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-* See the License for the specific language governing permissions and
-* limitations under the License.
-*/
-#ifndef ActiveMQObjectMessage_hpp_
-#define ActiveMQObjectMessage_hpp_
-
-#include <string>
-#include "command/ActiveMQMessage.hpp"
-    
-
-#include "util/ifr/ap.hpp"
-#include "util/ifr/p.hpp"
-
-namespace apache
-{
-  namespace activemq
-  {
-    namespace client
-    {
-      namespace command
-      {
-        using namespace ifr;
-        using namespace std;
-        using namespace apache::activemq::client;
-
-/*
- *
- *  Marshalling code for Open Wire Format for ActiveMQObjectMessage
- *
- *
- *  NOTE!: This file is autogenerated - do not modify!
- *         if you need to make a change, please see the Groovy scripts in the
- *         activemq-core module
- *
- */
-class ActiveMQObjectMessage : public ActiveMQMessage
-{
-private:
-
-public:
-    const static int TYPE = 26;
-
-public:
-    ActiveMQObjectMessage() ;
-    virtual ~ActiveMQObjectMessage() ;
-
-    virtual int getCommandType() ;
-
-
-} ;
-
-/* namespace */
-      }
-    }
-  }
-}
-
-#endif /*ActiveMQObjectMessage_hpp_*/
+/*
* Copyright 2006 The Apache Software Foundation or its licensors, as
* applicable.
*
* Licensed under the Apache License, Version 2.0 (the "License");
* you may not use this file except in compliance with the License.
* You may obtain a copy of the License at
*
*     http://www.apache.org/licenses/LICENSE-2.0
*
* Unless required by applicable law or agreed to in writing, software
* distributed under the License is distributed on an "AS IS" BASIS,
* WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
* See the License for the specific language governing permissions and
* limitations under the License.
*/
#ifndef ActiveMQObjectMessage_hpp_
#define ActiveMQObjectMessage_hpp_

#include <string>
#include "command/ActiveMQMessage.hpp"
    

#include "util/ifr/ap.hpp"
#include "util/ifr/p.hpp"

namespace apache
{
  namespace activemq
  {
    namespace client
    {
      namespace command
      {
        using namespace ifr;
        using namespace std;
     
    using namespace apache::activemq::client;

/*
 *
 *  Marshalling code for Open Wire Format for ActiveMQObjectMessage
 *
 *
 *  NOTE!: This file is autogenerated - do not modify!
 *         if you need to make a change, please see the Groovy scripts in the
 *         activemq-core module
 *
 */
class ActiveMQObjectMessage : public ActiveMQMessage
{
private:

public:
    const static int TYPE = 26;

public:
    ActiveMQObjectMessage() ;
    virtual ~ActiveMQObjectMessage() ;

    virtual int getCommandType() ;


} ;

/* namespace */
      }
    }
  }
}

#endif /*ActiveMQObjectMessage_hpp_*/
\ No newline at end of file

Modified: incubator/activemq/trunk/openwire-cpp/src/command/ConnectionError.hpp
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/openwire-cpp/src/command/ConnectionError.hpp?rev=383749&r1=383748&r2=383749&view=diff
==============================================================================
--- incubator/activemq/trunk/openwire-cpp/src/command/ConnectionError.hpp (original)
+++ incubator/activemq/trunk/openwire-cpp/src/command/ConnectionError.hpp Mon Mar  6 18:32:50 2006
@@ -1,81 +1 @@
-/*
-* Copyright 2006 The Apache Software Foundation or its licensors, as
-* applicable.
-*
-* Licensed under the Apache License, Version 2.0 (the "License");
-* you may not use this file except in compliance with the License.
-* You may obtain a copy of the License at
-*
-*     http://www.apache.org/licenses/LICENSE-2.0
-*
-* Unless required by applicable law or agreed to in writing, software
-* distributed under the License is distributed on an "AS IS" BASIS,
-* WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-* See the License for the specific language governing permissions and
-* limitations under the License.
-*/
-#ifndef ConnectionError_hpp_
-#define ConnectionError_hpp_
-
-#include <string>
-#include "command/BaseCommand.hpp"
-    
-#include "BrokerError.hpp"
-#include "command/ConnectionId.hpp"
-
-#include "util/ifr/ap.hpp"
-#include "util/ifr/p.hpp"
-
-namespace apache
-{
-  namespace activemq
-  {
-    namespace client
-    {
-      namespace command
-      {
-        using namespace ifr;
-        using namespace std;
-        using namespace apache::activemq::client;
-
-/*
- *
- *  Marshalling code for Open Wire Format for ConnectionError
- *
- *
- *  NOTE!: This file is autogenerated - do not modify!
- *         if you need to make a change, please see the Groovy scripts in the
- *         activemq-core module
- *
- */
-class ConnectionError : public BaseCommand
-{
-private:
-    p<BrokerError> exception ;
-    p<ConnectionId> connectionId ;
-
-public:
-    const static int TYPE = 16;
-
-public:
-    ConnectionError() ;
-    virtual ~ConnectionError() ;
-
-    virtual int getCommandType() ;
-
-    virtual p<BrokerError> getException() ;
-    virtual void setException(p<BrokerError> exception) ;
-
-    virtual p<ConnectionId> getConnectionId() ;
-    virtual void setConnectionId(p<ConnectionId> connectionId) ;
-
-
-} ;
-
-/* namespace */
-      }
-    }
-  }
-}
-
-#endif /*ConnectionError_hpp_*/
+/*
* Copyright 2006 The Apache Software Foundation or its licensors, as
* applicable.
*
* Licensed under the Apache License, Version 2.0 (the "License");
* you may not use this file except in compliance with the License.
* You may obtain a copy of the License at
*
*     http://www.apache.org/licenses/LICENSE-2.0
*
* Unless required by applicable law or agreed to in writing, software
* distributed under the License is distributed on an "AS IS" BASIS,
* WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
* See the License for the specific language governing permissions and
* limitations under the License.
*/
#ifndef ConnectionError_hpp_
#define ConnectionError_hpp_

#include <string>
#include "command/BaseCommand.hpp"
    
#include "BrokerError.hpp"
#include "command/ConnectionId.hpp"

#include "util/ifr/ap.hpp"
#include "util/ifr/p.hpp"

namespace apache
{
  namespace activemq
  {
    namespace client
    {
      namespace command
      {
        using na
 mespace ifr;
        using namespace std;
        using namespace apache::activemq::client;

/*
 *
 *  Marshalling code for Open Wire Format for ConnectionError
 *
 *
 *  NOTE!: This file is autogenerated - do not modify!
 *         if you need to make a change, please see the Groovy scripts in the
 *         activemq-core module
 *
 */
class ConnectionError : public BaseCommand
{
private:
    p<BrokerError> exception ;
    p<ConnectionId> connectionId ;

public:
    const static int TYPE = 16;

public:
    ConnectionError() ;
    virtual ~ConnectionError() ;

    virtual int getCommandType() ;

    virtual p<BrokerError> getException() ;
    virtual void setException(p<BrokerError> exception) ;

    virtual p<ConnectionId> getConnectionId() ;
    virtual void setConnectionId(p<ConnectionId> connectionId) ;


} ;

/* namespace */
      }
    }
  }
}

#endif /*ConnectionError_hpp_*/
\ No newline at end of file

Modified: incubator/activemq/trunk/openwire-cpp/src/command/ConsumerInfo.cpp
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/openwire-cpp/src/command/ConsumerInfo.cpp?rev=383749&r1=383748&r2=383749&view=diff
==============================================================================
--- incubator/activemq/trunk/openwire-cpp/src/command/ConsumerInfo.cpp (original)
+++ incubator/activemq/trunk/openwire-cpp/src/command/ConsumerInfo.cpp Mon Mar  6 18:32:50 2006
@@ -43,6 +43,7 @@
     this->retroactive = 0 ;
     this->priority = 0 ;
     this->brokerPath = 0 ;
+    this->additionalPredicate = 0 ;
     this->networkSubscription = 0 ;
 }
 
@@ -191,6 +192,17 @@
 void ConsumerInfo::setBrokerPath(ap<BrokerId> brokerPath)
 {
     this->brokerPath = brokerPath ;
+}
+
+        
+p<BooleanExpression> ConsumerInfo::getAdditionalPredicate()
+{
+    return additionalPredicate ;
+}
+
+void ConsumerInfo::setAdditionalPredicate(p<BooleanExpression> additionalPredicate)
+{
+    this->additionalPredicate = additionalPredicate ;
 }
 
         

Modified: incubator/activemq/trunk/openwire-cpp/src/command/ConsumerInfo.hpp
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/openwire-cpp/src/command/ConsumerInfo.hpp?rev=383749&r1=383748&r2=383749&view=diff
==============================================================================
--- incubator/activemq/trunk/openwire-cpp/src/command/ConsumerInfo.hpp (original)
+++ incubator/activemq/trunk/openwire-cpp/src/command/ConsumerInfo.hpp Mon Mar  6 18:32:50 2006
@@ -23,6 +23,7 @@
 #include "command/ConsumerId.hpp"
 #include "command/ActiveMQDestination.hpp"
 #include "command/BrokerId.hpp"
+#include "command/BooleanExpression.hpp"
 
 #include "util/ifr/ap.hpp"
 #include "util/ifr/p.hpp"
@@ -65,6 +66,7 @@
     bool retroactive ;
     char priority ;
     ap<BrokerId> brokerPath ;
+    p<BooleanExpression> additionalPredicate ;
     bool networkSubscription ;
 
 public:
@@ -114,6 +116,9 @@
 
     virtual ap<BrokerId> getBrokerPath() ;
     virtual void setBrokerPath(ap<BrokerId> brokerPath) ;
+
+    virtual p<BooleanExpression> getAdditionalPredicate() ;
+    virtual void setAdditionalPredicate(p<BooleanExpression> additionalPredicate) ;
 
     virtual bool getNetworkSubscription() ;
     virtual void setNetworkSubscription(bool networkSubscription) ;

Modified: incubator/activemq/trunk/openwire-cpp/src/command/ControlCommand.hpp
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/openwire-cpp/src/command/ControlCommand.hpp?rev=383749&r1=383748&r2=383749&view=diff
==============================================================================
--- incubator/activemq/trunk/openwire-cpp/src/command/ControlCommand.hpp (original)
+++ incubator/activemq/trunk/openwire-cpp/src/command/ControlCommand.hpp Mon Mar  6 18:32:50 2006
@@ -1,75 +1 @@
-/*
-* Copyright 2006 The Apache Software Foundation or its licensors, as
-* applicable.
-*
-* Licensed under the Apache License, Version 2.0 (the "License");
-* you may not use this file except in compliance with the License.
-* You may obtain a copy of the License at
-*
-*     http://www.apache.org/licenses/LICENSE-2.0
-*
-* Unless required by applicable law or agreed to in writing, software
-* distributed under the License is distributed on an "AS IS" BASIS,
-* WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-* See the License for the specific language governing permissions and
-* limitations under the License.
-*/
-#ifndef ControlCommand_hpp_
-#define ControlCommand_hpp_
-
-#include <string>
-#include "command/BaseCommand.hpp"
-    
-
-#include "util/ifr/ap.hpp"
-#include "util/ifr/p.hpp"
-
-namespace apache
-{
-  namespace activemq
-  {
-    namespace client
-    {
-      namespace command
-      {
-        using namespace ifr;
-        using namespace std;
-        using namespace apache::activemq::client;
-
-/*
- *
- *  Marshalling code for Open Wire Format for ControlCommand
- *
- *
- *  NOTE!: This file is autogenerated - do not modify!
- *         if you need to make a change, please see the Groovy scripts in the
- *         activemq-core module
- *
- */
-class ControlCommand : public BaseCommand
-{
-private:
-    p<string> command ;
-
-public:
-    const static int TYPE = 14;
-
-public:
-    ControlCommand() ;
-    virtual ~ControlCommand() ;
-
-    virtual int getCommandType() ;
-
-    virtual p<string> getCommand() ;
-    virtual void setCommand(p<string> command) ;
-
-
-} ;
-
-/* namespace */
-      }
-    }
-  }
-}
-
-#endif /*ControlCommand_hpp_*/
+/*
* Copyright 2006 The Apache Software Foundation or its licensors, as
* applicable.
*
* Licensed under the Apache License, Version 2.0 (the "License");
* you may not use this file except in compliance with the License.
* You may obtain a copy of the License at
*
*     http://www.apache.org/licenses/LICENSE-2.0
*
* Unless required by applicable law or agreed to in writing, software
* distributed under the License is distributed on an "AS IS" BASIS,
* WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
* See the License for the specific language governing permissions and
* limitations under the License.
*/
#ifndef ControlCommand_hpp_
#define ControlCommand_hpp_

#include <string>
#include "command/BaseCommand.hpp"
    

#include "util/ifr/ap.hpp"
#include "util/ifr/p.hpp"

namespace apache
{
  namespace activemq
  {
    namespace client
    {
      namespace command
      {
        using namespace ifr;
        using namespace std;
        using namespace
  apache::activemq::client;

/*
 *
 *  Marshalling code for Open Wire Format for ControlCommand
 *
 *
 *  NOTE!: This file is autogenerated - do not modify!
 *         if you need to make a change, please see the Groovy scripts in the
 *         activemq-core module
 *
 */
class ControlCommand : public BaseCommand
{
private:
    p<string> command ;

public:
    const static int TYPE = 14;

public:
    ControlCommand() ;
    virtual ~ControlCommand() ;

    virtual int getCommandType() ;

    virtual p<string> getCommand() ;
    virtual void setCommand(p<string> command) ;


} ;

/* namespace */
      }
    }
  }
}

#endif /*ControlCommand_hpp_*/
\ No newline at end of file

Modified: incubator/activemq/trunk/openwire-cpp/src/command/DataArrayResponse.hpp
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/openwire-cpp/src/command/DataArrayResponse.hpp?rev=383749&r1=383748&r2=383749&view=diff
==============================================================================
--- incubator/activemq/trunk/openwire-cpp/src/command/DataArrayResponse.hpp (original)
+++ incubator/activemq/trunk/openwire-cpp/src/command/DataArrayResponse.hpp Mon Mar  6 18:32:50 2006
@@ -1,76 +1 @@
-/*
-* Copyright 2006 The Apache Software Foundation or its licensors, as
-* applicable.
-*
-* Licensed under the Apache License, Version 2.0 (the "License");
-* you may not use this file except in compliance with the License.
-* You may obtain a copy of the License at
-*
-*     http://www.apache.org/licenses/LICENSE-2.0
-*
-* Unless required by applicable law or agreed to in writing, software
-* distributed under the License is distributed on an "AS IS" BASIS,
-* WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-* See the License for the specific language governing permissions and
-* limitations under the License.
-*/
-#ifndef DataArrayResponse_hpp_
-#define DataArrayResponse_hpp_
-
-#include <string>
-#include "command/Response.hpp"
-    
-#include "command/IDataStructure.hpp"
-
-#include "util/ifr/ap.hpp"
-#include "util/ifr/p.hpp"
-
-namespace apache
-{
-  namespace activemq
-  {
-    namespace client
-    {
-      namespace command
-      {
-        using namespace ifr;
-        using namespace std;
-        using namespace apache::activemq::client;
-
-/*
- *
- *  Marshalling code for Open Wire Format for DataArrayResponse
- *
- *
- *  NOTE!: This file is autogenerated - do not modify!
- *         if you need to make a change, please see the Groovy scripts in the
- *         activemq-core module
- *
- */
-class DataArrayResponse : public Response
-{
-private:
-    ap<IDataStructure> data ;
-
-public:
-    const static int TYPE = 33;
-
-public:
-    DataArrayResponse() ;
-    virtual ~DataArrayResponse() ;
-
-    virtual int getCommandType() ;
-
-    virtual ap<IDataStructure> getData() ;
-    virtual void setData(ap<IDataStructure> data) ;
-
-
-} ;
-
-/* namespace */
-      }
-    }
-  }
-}
-
-#endif /*DataArrayResponse_hpp_*/
+/*
* Copyright 2006 The Apache Software Foundation or its licensors, as
* applicable.
*
* Licensed under the Apache License, Version 2.0 (the "License");
* you may not use this file except in compliance with the License.
* You may obtain a copy of the License at
*
*     http://www.apache.org/licenses/LICENSE-2.0
*
* Unless required by applicable law or agreed to in writing, software
* distributed under the License is distributed on an "AS IS" BASIS,
* WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
* See the License for the specific language governing permissions and
* limitations under the License.
*/
#ifndef DataArrayResponse_hpp_
#define DataArrayResponse_hpp_

#include <string>
#include "command/Response.hpp"
    
#include "command/IDataStructure.hpp"

#include "util/ifr/ap.hpp"
#include "util/ifr/p.hpp"

namespace apache
{
  namespace activemq
  {
    namespace client
    {
      namespace command
      {
        using namespace ifr;
        usi
 ng namespace std;
        using namespace apache::activemq::client;

/*
 *
 *  Marshalling code for Open Wire Format for DataArrayResponse
 *
 *
 *  NOTE!: This file is autogenerated - do not modify!
 *         if you need to make a change, please see the Groovy scripts in the
 *         activemq-core module
 *
 */
class DataArrayResponse : public Response
{
private:
    ap<IDataStructure> data ;

public:
    const static int TYPE = 33;

public:
    DataArrayResponse() ;
    virtual ~DataArrayResponse() ;

    virtual int getCommandType() ;

    virtual ap<IDataStructure> getData() ;
    virtual void setData(ap<IDataStructure> data) ;


} ;

/* namespace */
      }
    }
  }
}

#endif /*DataArrayResponse_hpp_*/
\ No newline at end of file

Modified: incubator/activemq/trunk/openwire-cpp/src/command/DataResponse.hpp
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/openwire-cpp/src/command/DataResponse.hpp?rev=383749&r1=383748&r2=383749&view=diff
==============================================================================
--- incubator/activemq/trunk/openwire-cpp/src/command/DataResponse.hpp (original)
+++ incubator/activemq/trunk/openwire-cpp/src/command/DataResponse.hpp Mon Mar  6 18:32:50 2006
@@ -1,76 +1 @@
-/*
-* Copyright 2006 The Apache Software Foundation or its licensors, as
-* applicable.
-*
-* Licensed under the Apache License, Version 2.0 (the "License");
-* you may not use this file except in compliance with the License.
-* You may obtain a copy of the License at
-*
-*     http://www.apache.org/licenses/LICENSE-2.0
-*
-* Unless required by applicable law or agreed to in writing, software
-* distributed under the License is distributed on an "AS IS" BASIS,
-* WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-* See the License for the specific language governing permissions and
-* limitations under the License.
-*/
-#ifndef DataResponse_hpp_
-#define DataResponse_hpp_
-
-#include <string>
-#include "command/Response.hpp"
-    
-#include "command/IDataStructure.hpp"
-
-#include "util/ifr/ap.hpp"
-#include "util/ifr/p.hpp"
-
-namespace apache
-{
-  namespace activemq
-  {
-    namespace client
-    {
-      namespace command
-      {
-        using namespace ifr;
-        using namespace std;
-        using namespace apache::activemq::client;
-
-/*
- *
- *  Marshalling code for Open Wire Format for DataResponse
- *
- *
- *  NOTE!: This file is autogenerated - do not modify!
- *         if you need to make a change, please see the Groovy scripts in the
- *         activemq-core module
- *
- */
-class DataResponse : public Response
-{
-private:
-    p<IDataStructure> data ;
-
-public:
-    const static int TYPE = 32;
-
-public:
-    DataResponse() ;
-    virtual ~DataResponse() ;
-
-    virtual int getCommandType() ;
-
-    virtual p<IDataStructure> getData() ;
-    virtual void setData(p<IDataStructure> data) ;
-
-
-} ;
-
-/* namespace */
-      }
-    }
-  }
-}
-
-#endif /*DataResponse_hpp_*/
+/*
* Copyright 2006 The Apache Software Foundation or its licensors, as
* applicable.
*
* Licensed under the Apache License, Version 2.0 (the "License");
* you may not use this file except in compliance with the License.
* You may obtain a copy of the License at
*
*     http://www.apache.org/licenses/LICENSE-2.0
*
* Unless required by applicable law or agreed to in writing, software
* distributed under the License is distributed on an "AS IS" BASIS,
* WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
* See the License for the specific language governing permissions and
* limitations under the License.
*/
#ifndef DataResponse_hpp_
#define DataResponse_hpp_

#include <string>
#include "command/Response.hpp"
    
#include "command/IDataStructure.hpp"

#include "util/ifr/ap.hpp"
#include "util/ifr/p.hpp"

namespace apache
{
  namespace activemq
  {
    namespace client
    {
      namespace command
      {
        using namespace ifr;
        using namespa
 ce std;
        using namespace apache::activemq::client;

/*
 *
 *  Marshalling code for Open Wire Format for DataResponse
 *
 *
 *  NOTE!: This file is autogenerated - do not modify!
 *         if you need to make a change, please see the Groovy scripts in the
 *         activemq-core module
 *
 */
class DataResponse : public Response
{
private:
    p<IDataStructure> data ;

public:
    const static int TYPE = 32;

public:
    DataResponse() ;
    virtual ~DataResponse() ;

    virtual int getCommandType() ;

    virtual p<IDataStructure> getData() ;
    virtual void setData(p<IDataStructure> data) ;


} ;

/* namespace */
      }
    }
  }
}

#endif /*DataResponse_hpp_*/
\ No newline at end of file

Modified: incubator/activemq/trunk/openwire-cpp/src/command/DestinationInfo.hpp
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/openwire-cpp/src/command/DestinationInfo.hpp?rev=383749&r1=383748&r2=383749&view=diff
==============================================================================
--- incubator/activemq/trunk/openwire-cpp/src/command/DestinationInfo.hpp (original)
+++ incubator/activemq/trunk/openwire-cpp/src/command/DestinationInfo.hpp Mon Mar  6 18:32:50 2006
@@ -1,94 +1 @@
-/*
-* Copyright 2006 The Apache Software Foundation or its licensors, as
-* applicable.
-*
-* Licensed under the Apache License, Version 2.0 (the "License");
-* you may not use this file except in compliance with the License.
-* You may obtain a copy of the License at
-*
-*     http://www.apache.org/licenses/LICENSE-2.0
-*
-* Unless required by applicable law or agreed to in writing, software
-* distributed under the License is distributed on an "AS IS" BASIS,
-* WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-* See the License for the specific language governing permissions and
-* limitations under the License.
-*/
-#ifndef DestinationInfo_hpp_
-#define DestinationInfo_hpp_
-
-#include <string>
-#include "command/BaseCommand.hpp"
-    
-#include "command/ConnectionId.hpp"
-#include "command/ActiveMQDestination.hpp"
-#include "command/BrokerId.hpp"
-
-#include "util/ifr/ap.hpp"
-#include "util/ifr/p.hpp"
-
-namespace apache
-{
-  namespace activemq
-  {
-    namespace client
-    {
-      namespace command
-      {
-        using namespace ifr;
-        using namespace std;
-        using namespace apache::activemq::client;
-
-/*
- *
- *  Marshalling code for Open Wire Format for DestinationInfo
- *
- *
- *  NOTE!: This file is autogenerated - do not modify!
- *         if you need to make a change, please see the Groovy scripts in the
- *         activemq-core module
- *
- */
-class DestinationInfo : public BaseCommand
-{
-private:
-    p<ConnectionId> connectionId ;
-    p<ActiveMQDestination> destination ;
-    char operationType ;
-    long long timeout ;
-    ap<BrokerId> brokerPath ;
-
-public:
-    const static int TYPE = 8;
-
-public:
-    DestinationInfo() ;
-    virtual ~DestinationInfo() ;
-
-    virtual int getCommandType() ;
-
-    virtual p<ConnectionId> getConnectionId() ;
-    virtual void setConnectionId(p<ConnectionId> connectionId) ;
-
-    virtual p<ActiveMQDestination> getDestination() ;
-    virtual void setDestination(p<ActiveMQDestination> destination) ;
-
-    virtual char getOperationType() ;
-    virtual void setOperationType(char operationType) ;
-
-    virtual long long getTimeout() ;
-    virtual void setTimeout(long long timeout) ;
-
-    virtual ap<BrokerId> getBrokerPath() ;
-    virtual void setBrokerPath(ap<BrokerId> brokerPath) ;
-
-
-} ;
-
-/* namespace */
-      }
-    }
-  }
-}
-
-#endif /*DestinationInfo_hpp_*/
+/*
* Copyright 2006 The Apache Software Foundation or its licensors, as
* applicable.
*
* Licensed under the Apache License, Version 2.0 (the "License");
* you may not use this file except in compliance with the License.
* You may obtain a copy of the License at
*
*     http://www.apache.org/licenses/LICENSE-2.0
*
* Unless required by applicable law or agreed to in writing, software
* distributed under the License is distributed on an "AS IS" BASIS,
* WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
* See the License for the specific language governing permissions and
* limitations under the License.
*/
#ifndef DestinationInfo_hpp_
#define DestinationInfo_hpp_

#include <string>
#include "command/BaseCommand.hpp"
    
#include "command/ConnectionId.hpp"
#include "command/ActiveMQDestination.hpp"
#include "command/BrokerId.hpp"

#include "util/ifr/ap.hpp"
#include "util/ifr/p.hpp"

namespace apache
{
  namespace activemq
  {
    namespace client
    {
       namespace command
      {
        using namespace ifr;
        using namespace std;
        using namespace apache::activemq::client;

/*
 *
 *  Marshalling code for Open Wire Format for DestinationInfo
 *
 *
 *  NOTE!: This file is autogenerated - do not modify!
 *         if you need to make a change, please see the Groovy scripts in the
 *         activemq-core module
 *
 */
class DestinationInfo : public BaseCommand
{
private:
    p<ConnectionId> connectionId ;
    p<ActiveMQDestination> destination ;
    char operationType ;
    long long timeout ;
    ap<BrokerId> brokerPath ;

public:
    const static int TYPE = 8;

public:
    DestinationInfo() ;
    virtual ~DestinationInfo() ;

    virtual int getCommandType() ;

    virtual p<ConnectionId> getConnectionId() ;
    virtual void setConnectionId(p<ConnectionId> connectionId) ;

    virtual p<ActiveMQDestination> getDestination() ;
    virtual void setDestination(p<ActiveMQDestination> destination) ;

    virtual
  char getOperationType() ;
    virtual void setOperationType(char operationType) ;

    virtual long long getTimeout() ;
    virtual void setTimeout(long long timeout) ;

    virtual ap<BrokerId> getBrokerPath() ;
    virtual void setBrokerPath(ap<BrokerId> brokerPath) ;


} ;

/* namespace */
      }
    }
  }
}

#endif /*DestinationInfo_hpp_*/
\ No newline at end of file

Modified: incubator/activemq/trunk/openwire-cpp/src/command/DiscoveryEvent.hpp
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/openwire-cpp/src/command/DiscoveryEvent.hpp?rev=383749&r1=383748&r2=383749&view=diff
==============================================================================
--- incubator/activemq/trunk/openwire-cpp/src/command/DiscoveryEvent.hpp (original)
+++ incubator/activemq/trunk/openwire-cpp/src/command/DiscoveryEvent.hpp Mon Mar  6 18:32:50 2006
@@ -1,79 +1 @@
-/*
-* Copyright 2006 The Apache Software Foundation or its licensors, as
-* applicable.
-*
-* Licensed under the Apache License, Version 2.0 (the "License");
-* you may not use this file except in compliance with the License.
-* You may obtain a copy of the License at
-*
-*     http://www.apache.org/licenses/LICENSE-2.0
-*
-* Unless required by applicable law or agreed to in writing, software
-* distributed under the License is distributed on an "AS IS" BASIS,
-* WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-* See the License for the specific language governing permissions and
-* limitations under the License.
-*/
-#ifndef DiscoveryEvent_hpp_
-#define DiscoveryEvent_hpp_
-
-#include <string>
-#include "command/AbstractCommand.hpp"
-    
-
-#include "util/ifr/ap.hpp"
-#include "util/ifr/p.hpp"
-
-namespace apache
-{
-  namespace activemq
-  {
-    namespace client
-    {
-      namespace command
-      {
-        using namespace ifr;
-        using namespace std;
-        using namespace apache::activemq::client;
-
-/*
- *
- *  Marshalling code for Open Wire Format for DiscoveryEvent
- *
- *
- *  NOTE!: This file is autogenerated - do not modify!
- *         if you need to make a change, please see the Groovy scripts in the
- *         activemq-core module
- *
- */
-class DiscoveryEvent : public AbstractCommand
-{
-private:
-    p<string> serviceName ;
-    p<string> brokerName ;
-
-public:
-    const static int TYPE = 40;
-
-public:
-    DiscoveryEvent() ;
-    virtual ~DiscoveryEvent() ;
-
-    virtual int getCommandType() ;
-
-    virtual p<string> getServiceName() ;
-    virtual void setServiceName(p<string> serviceName) ;
-
-    virtual p<string> getBrokerName() ;
-    virtual void setBrokerName(p<string> brokerName) ;
-
-
-} ;
-
-/* namespace */
-      }
-    }
-  }
-}
-
-#endif /*DiscoveryEvent_hpp_*/
+/*
* Copyright 2006 The Apache Software Foundation or its licensors, as
* applicable.
*
* Licensed under the Apache License, Version 2.0 (the "License");
* you may not use this file except in compliance with the License.
* You may obtain a copy of the License at
*
*     http://www.apache.org/licenses/LICENSE-2.0
*
* Unless required by applicable law or agreed to in writing, software
* distributed under the License is distributed on an "AS IS" BASIS,
* WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
* See the License for the specific language governing permissions and
* limitations under the License.
*/
#ifndef DiscoveryEvent_hpp_
#define DiscoveryEvent_hpp_

#include <string>
#include "command/AbstractCommand.hpp"
    

#include "util/ifr/ap.hpp"
#include "util/ifr/p.hpp"

namespace apache
{
  namespace activemq
  {
    namespace client
    {
      namespace command
      {
        using namespace ifr;
        using namespace std;
        using names
 pace apache::activemq::client;

/*
 *
 *  Marshalling code for Open Wire Format for DiscoveryEvent
 *
 *
 *  NOTE!: This file is autogenerated - do not modify!
 *         if you need to make a change, please see the Groovy scripts in the
 *         activemq-core module
 *
 */
class DiscoveryEvent : public AbstractCommand
{
private:
    p<string> serviceName ;
    p<string> brokerName ;

public:
    const static int TYPE = 40;

public:
    DiscoveryEvent() ;
    virtual ~DiscoveryEvent() ;

    virtual int getCommandType() ;

    virtual p<string> getServiceName() ;
    virtual void setServiceName(p<string> serviceName) ;

    virtual p<string> getBrokerName() ;
    virtual void setBrokerName(p<string> brokerName) ;


} ;

/* namespace */
      }
    }
  }
}

#endif /*DiscoveryEvent_hpp_*/
\ No newline at end of file

Modified: incubator/activemq/trunk/openwire-cpp/src/command/FlushCommand.hpp
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/openwire-cpp/src/command/FlushCommand.hpp?rev=383749&r1=383748&r2=383749&view=diff
==============================================================================
--- incubator/activemq/trunk/openwire-cpp/src/command/FlushCommand.hpp (original)
+++ incubator/activemq/trunk/openwire-cpp/src/command/FlushCommand.hpp Mon Mar  6 18:32:50 2006
@@ -1,71 +1 @@
-/*
-* Copyright 2006 The Apache Software Foundation or its licensors, as
-* applicable.
-*
-* Licensed under the Apache License, Version 2.0 (the "License");
-* you may not use this file except in compliance with the License.
-* You may obtain a copy of the License at
-*
-*     http://www.apache.org/licenses/LICENSE-2.0
-*
-* Unless required by applicable law or agreed to in writing, software
-* distributed under the License is distributed on an "AS IS" BASIS,
-* WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-* See the License for the specific language governing permissions and
-* limitations under the License.
-*/
-#ifndef FlushCommand_hpp_
-#define FlushCommand_hpp_
-
-#include <string>
-#include "command/BaseCommand.hpp"
-    
-
-#include "util/ifr/ap.hpp"
-#include "util/ifr/p.hpp"
-
-namespace apache
-{
-  namespace activemq
-  {
-    namespace client
-    {
-      namespace command
-      {
-        using namespace ifr;
-        using namespace std;
-        using namespace apache::activemq::client;
-
-/*
- *
- *  Marshalling code for Open Wire Format for FlushCommand
- *
- *
- *  NOTE!: This file is autogenerated - do not modify!
- *         if you need to make a change, please see the Groovy scripts in the
- *         activemq-core module
- *
- */
-class FlushCommand : public BaseCommand
-{
-private:
-
-public:
-    const static int TYPE = 15;
-
-public:
-    FlushCommand() ;
-    virtual ~FlushCommand() ;
-
-    virtual int getCommandType() ;
-
-
-} ;
-
-/* namespace */
-      }
-    }
-  }
-}
-
-#endif /*FlushCommand_hpp_*/
+/*
* Copyright 2006 The Apache Software Foundation or its licensors, as
* applicable.
*
* Licensed under the Apache License, Version 2.0 (the "License");
* you may not use this file except in compliance with the License.
* You may obtain a copy of the License at
*
*     http://www.apache.org/licenses/LICENSE-2.0
*
* Unless required by applicable law or agreed to in writing, software
* distributed under the License is distributed on an "AS IS" BASIS,
* WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
* See the License for the specific language governing permissions and
* limitations under the License.
*/
#ifndef FlushCommand_hpp_
#define FlushCommand_hpp_

#include <string>
#include "command/BaseCommand.hpp"
    

#include "util/ifr/ap.hpp"
#include "util/ifr/p.hpp"

namespace apache
{
  namespace activemq
  {
    namespace client
    {
      namespace command
      {
        using namespace ifr;
        using namespace std;
        using namespace apa
 che::activemq::client;

/*
 *
 *  Marshalling code for Open Wire Format for FlushCommand
 *
 *
 *  NOTE!: This file is autogenerated - do not modify!
 *         if you need to make a change, please see the Groovy scripts in the
 *         activemq-core module
 *
 */
class FlushCommand : public BaseCommand
{
private:

public:
    const static int TYPE = 15;

public:
    FlushCommand() ;
    virtual ~FlushCommand() ;

    virtual int getCommandType() ;


} ;

/* namespace */
      }
    }
  }
}

#endif /*FlushCommand_hpp_*/
\ No newline at end of file

Modified: incubator/activemq/trunk/openwire-cpp/src/command/IntegerResponse.hpp
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/openwire-cpp/src/command/IntegerResponse.hpp?rev=383749&r1=383748&r2=383749&view=diff
==============================================================================
--- incubator/activemq/trunk/openwire-cpp/src/command/IntegerResponse.hpp (original)
+++ incubator/activemq/trunk/openwire-cpp/src/command/IntegerResponse.hpp Mon Mar  6 18:32:50 2006
@@ -1,75 +1 @@
-/*
-* Copyright 2006 The Apache Software Foundation or its licensors, as
-* applicable.
-*
-* Licensed under the Apache License, Version 2.0 (the "License");
-* you may not use this file except in compliance with the License.
-* You may obtain a copy of the License at
-*
-*     http://www.apache.org/licenses/LICENSE-2.0
-*
-* Unless required by applicable law or agreed to in writing, software
-* distributed under the License is distributed on an "AS IS" BASIS,
-* WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-* See the License for the specific language governing permissions and
-* limitations under the License.
-*/
-#ifndef IntegerResponse_hpp_
-#define IntegerResponse_hpp_
-
-#include <string>
-#include "command/Response.hpp"
-    
-
-#include "util/ifr/ap.hpp"
-#include "util/ifr/p.hpp"
-
-namespace apache
-{
-  namespace activemq
-  {
-    namespace client
-    {
-      namespace command
-      {
-        using namespace ifr;
-        using namespace std;
-        using namespace apache::activemq::client;
-
-/*
- *
- *  Marshalling code for Open Wire Format for IntegerResponse
- *
- *
- *  NOTE!: This file is autogenerated - do not modify!
- *         if you need to make a change, please see the Groovy scripts in the
- *         activemq-core module
- *
- */
-class IntegerResponse : public Response
-{
-private:
-    int result ;
-
-public:
-    const static int TYPE = 34;
-
-public:
-    IntegerResponse() ;
-    virtual ~IntegerResponse() ;
-
-    virtual int getCommandType() ;
-
-    virtual int getResult() ;
-    virtual void setResult(int result) ;
-
-
-} ;
-
-/* namespace */
-      }
-    }
-  }
-}
-
-#endif /*IntegerResponse_hpp_*/
+/*
* Copyright 2006 The Apache Software Foundation or its licensors, as
* applicable.
*
* Licensed under the Apache License, Version 2.0 (the "License");
* you may not use this file except in compliance with the License.
* You may obtain a copy of the License at
*
*     http://www.apache.org/licenses/LICENSE-2.0
*
* Unless required by applicable law or agreed to in writing, software
* distributed under the License is distributed on an "AS IS" BASIS,
* WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
* See the License for the specific language governing permissions and
* limitations under the License.
*/
#ifndef IntegerResponse_hpp_
#define IntegerResponse_hpp_

#include <string>
#include "command/Response.hpp"
    

#include "util/ifr/ap.hpp"
#include "util/ifr/p.hpp"

namespace apache
{
  namespace activemq
  {
    namespace client
    {
      namespace command
      {
        using namespace ifr;
        using namespace std;
        using namespace 
 apache::activemq::client;

/*
 *
 *  Marshalling code for Open Wire Format for IntegerResponse
 *
 *
 *  NOTE!: This file is autogenerated - do not modify!
 *         if you need to make a change, please see the Groovy scripts in the
 *         activemq-core module
 *
 */
class IntegerResponse : public Response
{
private:
    int result ;

public:
    const static int TYPE = 34;

public:
    IntegerResponse() ;
    virtual ~IntegerResponse() ;

    virtual int getCommandType() ;

    virtual int getResult() ;
    virtual void setResult(int result) ;


} ;

/* namespace */
      }
    }
  }
}

#endif /*IntegerResponse_hpp_*/
\ No newline at end of file

Modified: incubator/activemq/trunk/openwire-cpp/src/command/JournalQueueAck.hpp
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/openwire-cpp/src/command/JournalQueueAck.hpp?rev=383749&r1=383748&r2=383749&view=diff
==============================================================================
--- incubator/activemq/trunk/openwire-cpp/src/command/JournalQueueAck.hpp (original)
+++ incubator/activemq/trunk/openwire-cpp/src/command/JournalQueueAck.hpp Mon Mar  6 18:32:50 2006
@@ -1,81 +1 @@
-/*
-* Copyright 2006 The Apache Software Foundation or its licensors, as
-* applicable.
-*
-* Licensed under the Apache License, Version 2.0 (the "License");
-* you may not use this file except in compliance with the License.
-* You may obtain a copy of the License at
-*
-*     http://www.apache.org/licenses/LICENSE-2.0
-*
-* Unless required by applicable law or agreed to in writing, software
-* distributed under the License is distributed on an "AS IS" BASIS,
-* WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-* See the License for the specific language governing permissions and
-* limitations under the License.
-*/
-#ifndef JournalQueueAck_hpp_
-#define JournalQueueAck_hpp_
-
-#include <string>
-#include "command/AbstractCommand.hpp"
-    
-#include "command/ActiveMQDestination.hpp"
-#include "command/MessageAck.hpp"
-
-#include "util/ifr/ap.hpp"
-#include "util/ifr/p.hpp"
-
-namespace apache
-{
-  namespace activemq
-  {
-    namespace client
-    {
-      namespace command
-      {
-        using namespace ifr;
-        using namespace std;
-        using namespace apache::activemq::client;
-
-/*
- *
- *  Marshalling code for Open Wire Format for JournalQueueAck
- *
- *
- *  NOTE!: This file is autogenerated - do not modify!
- *         if you need to make a change, please see the Groovy scripts in the
- *         activemq-core module
- *
- */
-class JournalQueueAck : public AbstractCommand
-{
-private:
-    p<ActiveMQDestination> destination ;
-    p<MessageAck> messageAck ;
-
-public:
-    const static int TYPE = 52;
-
-public:
-    JournalQueueAck() ;
-    virtual ~JournalQueueAck() ;
-
-    virtual int getCommandType() ;
-
-    virtual p<ActiveMQDestination> getDestination() ;
-    virtual void setDestination(p<ActiveMQDestination> destination) ;
-
-    virtual p<MessageAck> getMessageAck() ;
-    virtual void setMessageAck(p<MessageAck> messageAck) ;
-
-
-} ;
-
-/* namespace */
-      }
-    }
-  }
-}
-
-#endif /*JournalQueueAck_hpp_*/
+/*
* Copyright 2006 The Apache Software Foundation or its licensors, as
* applicable.
*
* Licensed under the Apache License, Version 2.0 (the "License");
* you may not use this file except in compliance with the License.
* You may obtain a copy of the License at
*
*     http://www.apache.org/licenses/LICENSE-2.0
*
* Unless required by applicable law or agreed to in writing, software
* distributed under the License is distributed on an "AS IS" BASIS,
* WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
* See the License for the specific language governing permissions and
* limitations under the License.
*/
#ifndef JournalQueueAck_hpp_
#define JournalQueueAck_hpp_

#include <string>
#include "command/AbstractCommand.hpp"
    
#include "command/ActiveMQDestination.hpp"
#include "command/MessageAck.hpp"

#include "util/ifr/ap.hpp"
#include "util/ifr/p.hpp"

namespace apache
{
  namespace activemq
  {
    namespace client
    {
      namespace command
      
 {
        using namespace ifr;
        using namespace std;
        using namespace apache::activemq::client;

/*
 *
 *  Marshalling code for Open Wire Format for JournalQueueAck
 *
 *
 *  NOTE!: This file is autogenerated - do not modify!
 *         if you need to make a change, please see the Groovy scripts in the
 *         activemq-core module
 *
 */
class JournalQueueAck : public AbstractCommand
{
private:
    p<ActiveMQDestination> destination ;
    p<MessageAck> messageAck ;

public:
    const static int TYPE = 52;

public:
    JournalQueueAck() ;
    virtual ~JournalQueueAck() ;

    virtual int getCommandType() ;

    virtual p<ActiveMQDestination> getDestination() ;
    virtual void setDestination(p<ActiveMQDestination> destination) ;

    virtual p<MessageAck> getMessageAck() ;
    virtual void setMessageAck(p<MessageAck> messageAck) ;


} ;

/* namespace */
      }
    }
  }
}

#endif /*JournalQueueAck_hpp_*/
\ No newline at end of file

Modified: incubator/activemq/trunk/openwire-cpp/src/command/JournalTopicAck.hpp
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/openwire-cpp/src/command/JournalTopicAck.hpp?rev=383749&r1=383748&r2=383749&view=diff
==============================================================================
--- incubator/activemq/trunk/openwire-cpp/src/command/JournalTopicAck.hpp (original)
+++ incubator/activemq/trunk/openwire-cpp/src/command/JournalTopicAck.hpp Mon Mar  6 18:32:50 2006
@@ -1,98 +1 @@
-/*
-* Copyright 2006 The Apache Software Foundation or its licensors, as
-* applicable.
-*
-* Licensed under the Apache License, Version 2.0 (the "License");
-* you may not use this file except in compliance with the License.
-* You may obtain a copy of the License at
-*
-*     http://www.apache.org/licenses/LICENSE-2.0
-*
-* Unless required by applicable law or agreed to in writing, software
-* distributed under the License is distributed on an "AS IS" BASIS,
-* WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-* See the License for the specific language governing permissions and
-* limitations under the License.
-*/
-#ifndef JournalTopicAck_hpp_
-#define JournalTopicAck_hpp_
-
-#include <string>
-#include "command/AbstractCommand.hpp"
-    
-#include "command/ActiveMQDestination.hpp"
-#include "command/MessageId.hpp"
-#include "command/TransactionId.hpp"
-
-#include "util/ifr/ap.hpp"
-#include "util/ifr/p.hpp"
-
-namespace apache
-{
-  namespace activemq
-  {
-    namespace client
-    {
-      namespace command
-      {
-        using namespace ifr;
-        using namespace std;
-        using namespace apache::activemq::client;
-
-/*
- *
- *  Marshalling code for Open Wire Format for JournalTopicAck
- *
- *
- *  NOTE!: This file is autogenerated - do not modify!
- *         if you need to make a change, please see the Groovy scripts in the
- *         activemq-core module
- *
- */
-class JournalTopicAck : public AbstractCommand
-{
-private:
-    p<ActiveMQDestination> destination ;
-    p<MessageId> messageId ;
-    long long messageSequenceId ;
-    p<string> subscritionName ;
-    p<string> clientId ;
-    p<TransactionId> transactionId ;
-
-public:
-    const static int TYPE = 50;
-
-public:
-    JournalTopicAck() ;
-    virtual ~JournalTopicAck() ;
-
-    virtual int getCommandType() ;
-
-    virtual p<ActiveMQDestination> getDestination() ;
-    virtual void setDestination(p<ActiveMQDestination> destination) ;
-
-    virtual p<MessageId> getMessageId() ;
-    virtual void setMessageId(p<MessageId> messageId) ;
-
-    virtual long long getMessageSequenceId() ;
-    virtual void setMessageSequenceId(long long messageSequenceId) ;
-
-    virtual p<string> getSubscritionName() ;
-    virtual void setSubscritionName(p<string> subscritionName) ;
-
-    virtual p<string> getClientId() ;
-    virtual void setClientId(p<string> clientId) ;
-
-    virtual p<TransactionId> getTransactionId() ;
-    virtual void setTransactionId(p<TransactionId> transactionId) ;
-
-
-} ;
-
-/* namespace */
-      }
-    }
-  }
-}
-
-#endif /*JournalTopicAck_hpp_*/
+/*
* Copyright 2006 The Apache Software Foundation or its licensors, as
* applicable.
*
* Licensed under the Apache License, Version 2.0 (the "License");
* you may not use this file except in compliance with the License.
* You may obtain a copy of the License at
*
*     http://www.apache.org/licenses/LICENSE-2.0
*
* Unless required by applicable law or agreed to in writing, software
* distributed under the License is distributed on an "AS IS" BASIS,
* WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
* See the License for the specific language governing permissions and
* limitations under the License.
*/
#ifndef JournalTopicAck_hpp_
#define JournalTopicAck_hpp_

#include <string>
#include "command/AbstractCommand.hpp"
    
#include "command/ActiveMQDestination.hpp"
#include "command/MessageId.hpp"
#include "command/TransactionId.hpp"

#include "util/ifr/ap.hpp"
#include "util/ifr/p.hpp"

namespace apache
{
  namespace activemq
  {
    namespace client
     {
      namespace command
      {
        using namespace ifr;
        using namespace std;
        using namespace apache::activemq::client;

/*
 *
 *  Marshalling code for Open Wire Format for JournalTopicAck
 *
 *
 *  NOTE!: This file is autogenerated - do not modify!
 *         if you need to make a change, please see the Groovy scripts in the
 *         activemq-core module
 *
 */
class JournalTopicAck : public AbstractCommand
{
private:
    p<ActiveMQDestination> destination ;
    p<MessageId> messageId ;
    long long messageSequenceId ;
    p<string> subscritionName ;
    p<string> clientId ;
    p<TransactionId> transactionId ;

public:
    const static int TYPE = 50;

public:
    JournalTopicAck() ;
    virtual ~JournalTopicAck() ;

    virtual int getCommandType() ;

    virtual p<ActiveMQDestination> getDestination() ;
    virtual void setDestination(p<ActiveMQDestination> destination) ;

    virtual p<MessageId> getMessageId() ;
    virtual void setMessageId
 (p<MessageId> messageId) ;

    virtual long long getMessageSequenceId() ;
    virtual void setMessageSequenceId(long long messageSequenceId) ;

    virtual p<string> getSubscritionName() ;
    virtual void setSubscritionName(p<string> subscritionName) ;

    virtual p<string> getClientId() ;
    virtual void setClientId(p<string> clientId) ;

    virtual p<TransactionId> getTransactionId() ;
    virtual void setTransactionId(p<TransactionId> transactionId) ;


} ;

/* namespace */
      }
    }
  }
}

#endif /*JournalTopicAck_hpp_*/
\ No newline at end of file

Modified: incubator/activemq/trunk/openwire-cpp/src/command/JournalTrace.hpp
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/openwire-cpp/src/command/JournalTrace.hpp?rev=383749&r1=383748&r2=383749&view=diff
==============================================================================
--- incubator/activemq/trunk/openwire-cpp/src/command/JournalTrace.hpp (original)
+++ incubator/activemq/trunk/openwire-cpp/src/command/JournalTrace.hpp Mon Mar  6 18:32:50 2006
@@ -1,75 +1 @@
-/*
-* Copyright 2006 The Apache Software Foundation or its licensors, as
-* applicable.
-*
-* Licensed under the Apache License, Version 2.0 (the "License");
-* you may not use this file except in compliance with the License.
-* You may obtain a copy of the License at
-*
-*     http://www.apache.org/licenses/LICENSE-2.0
-*
-* Unless required by applicable law or agreed to in writing, software
-* distributed under the License is distributed on an "AS IS" BASIS,
-* WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-* See the License for the specific language governing permissions and
-* limitations under the License.
-*/
-#ifndef JournalTrace_hpp_
-#define JournalTrace_hpp_
-
-#include <string>
-#include "command/AbstractCommand.hpp"
-    
-
-#include "util/ifr/ap.hpp"
-#include "util/ifr/p.hpp"
-
-namespace apache
-{
-  namespace activemq
-  {
-    namespace client
-    {
-      namespace command
-      {
-        using namespace ifr;
-        using namespace std;
-        using namespace apache::activemq::client;
-
-/*
- *
- *  Marshalling code for Open Wire Format for JournalTrace
- *
- *
- *  NOTE!: This file is autogenerated - do not modify!
- *         if you need to make a change, please see the Groovy scripts in the
- *         activemq-core module
- *
- */
-class JournalTrace : public AbstractCommand
-{
-private:
-    p<string> message ;
-
-public:
-    const static int TYPE = 53;
-
-public:
-    JournalTrace() ;
-    virtual ~JournalTrace() ;
-
-    virtual int getCommandType() ;
-
-    virtual p<string> getMessage() ;
-    virtual void setMessage(p<string> message) ;
-
-
-} ;
-
-/* namespace */
-      }
-    }
-  }
-}
-
-#endif /*JournalTrace_hpp_*/
+/*
* Copyright 2006 The Apache Software Foundation or its licensors, as
* applicable.
*
* Licensed under the Apache License, Version 2.0 (the "License");
* you may not use this file except in compliance with the License.
* You may obtain a copy of the License at
*
*     http://www.apache.org/licenses/LICENSE-2.0
*
* Unless required by applicable law or agreed to in writing, software
* distributed under the License is distributed on an "AS IS" BASIS,
* WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
* See the License for the specific language governing permissions and
* limitations under the License.
*/
#ifndef JournalTrace_hpp_
#define JournalTrace_hpp_

#include <string>
#include "command/AbstractCommand.hpp"
    

#include "util/ifr/ap.hpp"
#include "util/ifr/p.hpp"

namespace apache
{
  namespace activemq
  {
    namespace client
    {
      namespace command
      {
        using namespace ifr;
        using namespace std;
        using namespace
  apache::activemq::client;

/*
 *
 *  Marshalling code for Open Wire Format for JournalTrace
 *
 *
 *  NOTE!: This file is autogenerated - do not modify!
 *         if you need to make a change, please see the Groovy scripts in the
 *         activemq-core module
 *
 */
class JournalTrace : public AbstractCommand
{
private:
    p<string> message ;

public:
    const static int TYPE = 53;

public:
    JournalTrace() ;
    virtual ~JournalTrace() ;

    virtual int getCommandType() ;

    virtual p<string> getMessage() ;
    virtual void setMessage(p<string> message) ;


} ;

/* namespace */
      }
    }
  }
}

#endif /*JournalTrace_hpp_*/
\ No newline at end of file

Modified: incubator/activemq/trunk/openwire-cpp/src/command/JournalTransaction.hpp
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/openwire-cpp/src/command/JournalTransaction.hpp?rev=383749&r1=383748&r2=383749&view=diff
==============================================================================
--- incubator/activemq/trunk/openwire-cpp/src/command/JournalTransaction.hpp (original)
+++ incubator/activemq/trunk/openwire-cpp/src/command/JournalTransaction.hpp Mon Mar  6 18:32:50 2006
@@ -1,84 +1 @@
-/*
-* Copyright 2006 The Apache Software Foundation or its licensors, as
-* applicable.
-*
-* Licensed under the Apache License, Version 2.0 (the "License");
-* you may not use this file except in compliance with the License.
-* You may obtain a copy of the License at
-*
-*     http://www.apache.org/licenses/LICENSE-2.0
-*
-* Unless required by applicable law or agreed to in writing, software
-* distributed under the License is distributed on an "AS IS" BASIS,
-* WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-* See the License for the specific language governing permissions and
-* limitations under the License.
-*/
-#ifndef JournalTransaction_hpp_
-#define JournalTransaction_hpp_
-
-#include <string>
-#include "command/AbstractCommand.hpp"
-    
-#include "command/TransactionId.hpp"
-
-#include "util/ifr/ap.hpp"
-#include "util/ifr/p.hpp"
-
-namespace apache
-{
-  namespace activemq
-  {
-    namespace client
-    {
-      namespace command
-      {
-        using namespace ifr;
-        using namespace std;
-        using namespace apache::activemq::client;
-
-/*
- *
- *  Marshalling code for Open Wire Format for JournalTransaction
- *
- *
- *  NOTE!: This file is autogenerated - do not modify!
- *         if you need to make a change, please see the Groovy scripts in the
- *         activemq-core module
- *
- */
-class JournalTransaction : public AbstractCommand
-{
-private:
-    p<TransactionId> transactionId ;
-    char type ;
-    bool wasPrepared ;
-
-public:
-    const static int TYPE = 54;
-
-public:
-    JournalTransaction() ;
-    virtual ~JournalTransaction() ;
-
-    virtual int getCommandType() ;
-
-    virtual p<TransactionId> getTransactionId() ;
-    virtual void setTransactionId(p<TransactionId> transactionId) ;
-
-    virtual char getType() ;
-    virtual void setType(char type) ;
-
-    virtual bool getWasPrepared() ;
-    virtual void setWasPrepared(bool wasPrepared) ;
-
-
-} ;
-
-/* namespace */
-      }
-    }
-  }
-}
-
-#endif /*JournalTransaction_hpp_*/
+/*
* Copyright 2006 The Apache Software Foundation or its licensors, as
* applicable.
*
* Licensed under the Apache License, Version 2.0 (the "License");
* you may not use this file except in compliance with the License.
* You may obtain a copy of the License at
*
*     http://www.apache.org/licenses/LICENSE-2.0
*
* Unless required by applicable law or agreed to in writing, software
* distributed under the License is distributed on an "AS IS" BASIS,
* WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
* See the License for the specific language governing permissions and
* limitations under the License.
*/
#ifndef JournalTransaction_hpp_
#define JournalTransaction_hpp_

#include <string>
#include "command/AbstractCommand.hpp"
    
#include "command/TransactionId.hpp"

#include "util/ifr/ap.hpp"
#include "util/ifr/p.hpp"

namespace apache
{
  namespace activemq
  {
    namespace client
    {
      namespace command
      {
        using namespace ifr;
   
      using namespace std;
        using namespace apache::activemq::client;

/*
 *
 *  Marshalling code for Open Wire Format for JournalTransaction
 *
 *
 *  NOTE!: This file is autogenerated - do not modify!
 *         if you need to make a change, please see the Groovy scripts in the
 *         activemq-core module
 *
 */
class JournalTransaction : public AbstractCommand
{
private:
    p<TransactionId> transactionId ;
    char type ;
    bool wasPrepared ;

public:
    const static int TYPE = 54;

public:
    JournalTransaction() ;
    virtual ~JournalTransaction() ;

    virtual int getCommandType() ;

    virtual p<TransactionId> getTransactionId() ;
    virtual void setTransactionId(p<TransactionId> transactionId) ;

    virtual char getType() ;
    virtual void setType(char type) ;

    virtual bool getWasPrepared() ;
    virtual void setWasPrepared(bool wasPrepared) ;


} ;

/* namespace */
      }
    }
  }
}

#endif /*JournalTransaction_hpp_*/
\ No newline at end of file