Return-Path: Delivered-To: apmail-geronimo-activemq-commits-archive@www.apache.org Received: (qmail 83181 invoked from network); 2 Oct 2006 14:31:35 -0000 Received: from hermes.apache.org (HELO mail.apache.org) (209.237.227.199) by minotaur.apache.org with SMTP; 2 Oct 2006 14:31:35 -0000 Received: (qmail 70091 invoked by uid 500); 2 Oct 2006 14:31:35 -0000 Delivered-To: apmail-geronimo-activemq-commits-archive@geronimo.apache.org Received: (qmail 70042 invoked by uid 500); 2 Oct 2006 14:31:34 -0000 Mailing-List: contact activemq-commits-help@geronimo.apache.org; run by ezmlm Precedence: bulk List-Help: List-Unsubscribe: List-Post: List-Id: Reply-To: activemq-dev@geronimo.apache.org Delivered-To: mailing list activemq-commits@geronimo.apache.org Received: (qmail 70025 invoked by uid 99); 2 Oct 2006 14:31:34 -0000 Received: from idunn.apache.osuosl.org (HELO idunn.apache.osuosl.org) (140.211.166.84) by apache.org (qpsmtpd/0.29) with ESMTP; Mon, 02 Oct 2006 07:31:34 -0700 X-ASF-Spam-Status: No, hits=-9.4 required=5.0 tests=ALL_TRUSTED,NO_REAL_NAME Received: from [140.211.166.113] ([140.211.166.113:50669] helo=eris.apache.org) by idunn.apache.osuosl.org (ecelerity 2.1.1.8 r(12930)) with ESMTP id A8/6B-16499-0B221254 for ; Mon, 02 Oct 2006 07:31:16 -0700 Received: by eris.apache.org (Postfix, from userid 65534) id F154A1A9820; Mon, 2 Oct 2006 07:30:37 -0700 (PDT) Content-Type: text/plain; charset="utf-8" MIME-Version: 1.0 Content-Transfer-Encoding: 7bit Subject: svn commit: r452053 [3/17] - in /incubator/activemq/activemq-cpp/trunk/activemq-cpp/src: main/activemq/connector/openwire/ main/activemq/connector/openwire/commands/ main/activemq/connector/openwire/marshal/ main/activemq/connector/openwire/marshal/V2/... Date: Mon, 02 Oct 2006 14:30:22 -0000 To: activemq-commits@geronimo.apache.org From: tabish@apache.org X-Mailer: svnmailer-1.1.0 Message-Id: <20061002143037.F154A1A9820@eris.apache.org> X-Spam-Rating: minotaur.apache.org 1.6.2 0/1000/N Added: incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/ActiveMQMessage.h URL: http://svn.apache.org/viewvc/incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/ActiveMQMessage.h?view=auto&rev=452053 ============================================================================== --- incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/ActiveMQMessage.h (added) +++ incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/ActiveMQMessage.h Mon Oct 2 07:30:10 2006 @@ -0,0 +1,799 @@ +/* + * Licensed to the Apache Software Foundation (ASF) under one or more + * contributor license agreements. See the NOTICE file distributed with + * this work for additional information regarding copyright ownership. + * The ASF licenses this file to You under the Apache License, Version 2.0 + * (the "License"); you may not use this file except in compliance with + * the License. You may obtain a copy of the License at + * + * http://www.apache.org/licenses/LICENSE-2.0 + * + * Unless required by applicable law or agreed to in writing, software + * distributed under the License is distributed on an "AS IS" BASIS, + * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. + * See the License for the specific language governing permissions and + * limitations under the License. + */ + +#ifndef _ACTIVEMQ_CONNECTOR_OPENWIRE_COMMANDS_ACTIVEMQMESSAGE_H_ +#define _ACTIVEMQ_CONNECTOR_OPENWIRE_COMMANDS_ACTIVEMQMESSAGE_H_ + +#include +#include +#include + +namespace activemq{ +namespace connector{ +namespace openwire{ +namespace commands{ + + template< typename T > + class ActiveMQMessage : + public Message, + public core::ActiveMQMessage, + public T + { + public: + + static const unsigned char ID_ACTIVEMQ_MESSAGE = 23; + + public: + + ActiveMQMessage() {} + virtual ~ActiveMQMessage() {} + + virtual unsigned char getDataStructureType() const { + return ID_ACTIVEMQ_MESSAGE; + } + + public: // cms::Message + + /** + * Clonse this message exactly, returns a new instance that the + * caller is required to delete. + * @return new copy of this message + */ + virtual Message* clone(void) const = 0; + + /** + * Acknowledges all consumed messages of the session + * of this consumed message. + */ + virtual void acknowledge(void) const throw( CMSException ) { + try { + ackHandler->acknowledgeMessage( + dynamic_cast(this) ); + } + AMQ_CATCH_RETHROW( CMSException ) + AMQ_CATCHALL_THROW( CMSException ) + } + + /** + * Retrieves a reference to the properties object owned + * by this message + * @return A Properties Object reference + */ + virtual activemq::util::Properties& getProperties(void) = 0; + virtual const activemq::util::Properties& getProperties(void) const = 0; + + /** + * Get the Correlation Id for this message + * @return string representation of the correlation Id + */ + virtual const char* getCMSCorrelationId(void) const = 0; + + /** + * Sets the Correlation Id used by this message + * @param correlationId - String representing the correlation id. + */ + virtual void setCMSCorrelationId( const std::string& correlationId ) = 0; + + /** + * Gets the DeliveryMode for this message + * @return DeliveryMode enumerated value. + */ + virtual int getCMSDeliveryMode(void) const = 0; + + /** + * Sets the DeliveryMode for this message + * @param mode - DeliveryMode enumerated value. + */ + virtual void setCMSDeliveryMode( int mode ) = 0; + + /** + * Gets the Destination for this Message, returns a + * @return Destination object + */ + virtual const Destination* getCMSDestination(void) const = 0; + + /** + * Sets the Destination for this message + * @param destination - Destination Object + */ + virtual void setCMSDestination( const Destination* destination ) = 0; + + /** + * Gets the Expiration Time for this Message + * @return time value + */ + virtual long getCMSExpiration(void) const = 0; + + /** + * Sets the Expiration Time for this message + * @param expireTime - time value + */ + virtual void setCMSExpiration( long expireTime ) = 0; + + /** + * Gets the CMS Message Id for this Message + * @return time value + */ + virtual const char* getCMSMessageId(void) const = 0; + + /** + * Sets the CMS Message Id for this message + * @param id - time value + */ + virtual void setCMSMessageId( const std::string& id ) = 0; + + /** + * Gets the Priority Value for this Message + * @return priority value + */ + virtual int getCMSPriority(void) const = 0; + + /** + * Sets the Priority Value for this message + * @param priority - priority value for this message + */ + virtual void setCMSPriority( int priority ) = 0; + + /** + * Gets the Redelivered Flag for this Message + * @return redelivered value + */ + virtual bool getCMSRedelivered(void) const = 0; + + /** + * Sets the Redelivered Flag for this message + * @param redelivered - boolean redelivered value + */ + virtual void setCMSRedelivered( bool redelivered ) = 0; + + /** + * Gets the CMS Reply To Address for this Message + * @return Reply To Value + */ + virtual const char* getCMSReplyTo(void) const = 0; + + /** + * Sets the CMS Reply To Address for this message + * @param id - Reply To value + */ + virtual void setCMSReplyTo( const std::string& id ) = 0; + + /** + * Gets the Time Stamp for this Message + * @return time stamp value + */ + virtual long getCMSTimeStamp(void) const = 0; + + /** + * Sets the Time Stamp for this message + * @param timeStamp - integer time stamp value + */ + virtual void setCMSTimeStamp( long timeStamp ) = 0; + + /** + * Gets the CMS Message Type for this Message + * @return type value + */ + virtual const char* getCMSMessageType(void) const = 0; + + /** + * Sets the CMS Message Type for this message + * @param type - message type value string + */ + virtual void setCMSMessageType( const std::string& type ) = 0; + + public: // core::ActiveMQMessage + + /** + * Sets the Acknowledgement Handler that this Message will use + * when the Acknowledge method is called. + * @param handler ActiveMQAckHandler to call + */ + virtual void setAckHandler( ActiveMQAckHandler* handler ) { + this->ackHandler = handler; + } + + /** + * Gets the number of times this message has been redelivered. + * @return redelivery count + */ + virtual int getRedeliveryCount(void) const { + return redeliveryCount; + } + + /** + * Sets the count of the number of times this message has been + * redelivered + * @param count the redelivery count + */ + virtual void setRedeliveryCount( int count ) { + this->redeliveryCount = count; + } + + private: + + int redeliveryCount; + core::ActiveMQAckHandler* ackHandler; + + }; + +}}}} + +#endif /*_ACTIVEMQ_CONNECTOR_OPENWIRE_COMMANDS_ACTIVEMQMESSAGE_H_*/ + +// +//import java.io.IOException; +//import java.io.UnsupportedEncodingException; +//import java.util.Enumeration; +//import java.util.HashMap; +//import java.util.Iterator; +//import java.util.List; +//import java.util.Map; +//import java.util.Vector; +// +//import javax.jms.DeliveryMode; +//import javax.jms.Destination; +//import javax.jms.JMSException; +//import javax.jms.MessageFormatException; +//import javax.jms.MessageNotWriteableException; +// +//import org.apache.activemq.ActiveMQConnection; +//import org.apache.activemq.filter.PropertyExpression; +//import org.apache.activemq.state.CommandVisitor; +//import org.apache.activemq.util.Callback; +//import org.apache.activemq.util.JMSExceptionSupport; +//import org.apache.activemq.util.TypeConversionSupport; +// +///** +// * @openwire:marshaller code="23" +// * +// * @version $Revision:$ +// */ +//public class ActiveMQMessage extends Message implements javax.jms.Message { +// +// +// +// public Message copy() { +// ActiveMQMessage copy = new ActiveMQMessage(); +// copy(copy); +// return copy; +// } +// +// +// protected void copy(ActiveMQMessage copy) { +// super.copy(copy); +// copy.acknowledgeCallback = acknowledgeCallback; +// } +// +// +// public boolean equals(Object o) { +// if (this == o) +// return true; +// if (o == null || o.getClass() != getClass()) +// return false; +// +// ActiveMQMessage msg = (ActiveMQMessage) o; +// MessageId oMsg = msg.getMessageId(); +// MessageId thisMsg = this.getMessageId(); +// return thisMsg != null && oMsg != null && oMsg.equals(thisMsg); +// } +// + +// public void clearBody() throws JMSException { +// setContent(null); +// readOnlyBody = false; +// } +// +// public String getJMSMessageID() { +// MessageId messageId = this.getMessageId(); +// if (messageId == null) { +// return null; +// } +// return messageId.toString(); +// } +// +// /** +// * Seems to be invalid because the parameter doesn't initialize MessageId instance variables ProducerId and +// * ProducerSequenceId +// * +// * @param value +// * @throws JMSException +// */ +// public void setJMSMessageID(String value) throws JMSException { +// if( value !=null ) { +// try { +// MessageId id = new MessageId(value); +// this.setMessageId(id); +// } +// catch (NumberFormatException e) { +// // we must be some foreign JMS provider or strange user-supplied String +// // so lets set the IDs to be 1 +// MessageId id = new MessageId(); +// id.setTextView(value); +// this.setMessageId(messageId); +// } +// } else { +// this.setMessageId(null); +// } +// } +// +// /** +// * This will create an object of MessageId. For it to be valid, the instance variable ProducerId and +// * producerSequenceId must be initialized. +// * +// * @param producerId +// * @param producerSequenceId +// * @throws JMSException +// */ +// public void setJMSMessageID(ProducerId producerId, long producerSequenceId) throws JMSException { +// MessageId id = null; +// try { +// id = new MessageId(producerId, producerSequenceId); +// this.setMessageId(id); +// } catch (Throwable e) { +// throw JMSExceptionSupport.create("Invalid message id '" + id + "', reason: " + e.getMessage(), e); +// } +// } +// +// public long getJMSTimestamp() { +// return this.getTimestamp(); +// } +// +// public void setJMSTimestamp(long timestamp) { +// this.setTimestamp(timestamp); +// } +// +// public String getJMSCorrelationID() { +// return this.getCorrelationId(); +// } +// +// public void setJMSCorrelationID(String correlationId) { +// this.setCorrelationId(correlationId); +// } +// +// public byte[] getJMSCorrelationIDAsBytes() throws JMSException { +// return encodeString(this.getCorrelationId()); +// } +// +// public void setJMSCorrelationIDAsBytes(byte[] correlationId) throws JMSException { +// this.setCorrelationId(decodeString(correlationId)); +// } +// +// static protected String decodeString(byte[] data) throws JMSException { +// try { +// if (data == null) { +// return null; +// } +// return new String(data, "UTF-8"); +// } catch (UnsupportedEncodingException e) { +// throw new JMSException("Invalid UTF-8 encoding: " + e.getMessage()); +// } +// } +// +// static protected byte[] encodeString(String data) throws JMSException { +// try { +// if (data == null) { +// return null; +// } +// return data.getBytes("UTF-8"); +// } catch (UnsupportedEncodingException e) { +// throw new JMSException("Invalid UTF-8 encoding: " + e.getMessage()); +// } +// } +// +// public Destination getJMSReplyTo() { +// return this.getReplyTo(); +// } +// +// public void setJMSReplyTo(Destination destination) throws JMSException { +// this.setReplyTo(ActiveMQDestination.transform(destination)); +// } +// +// public Destination getJMSDestination() { +// return this.getDestination(); +// } +// +// public void setJMSDestination(Destination destination) throws JMSException { +// this.setDestination(ActiveMQDestination.transform(destination)); +// } +// +// public int getJMSDeliveryMode() { +// return this.isPersistent() ? DeliveryMode.PERSISTENT : DeliveryMode.NON_PERSISTENT; +// } +// +// public void setJMSDeliveryMode(int mode) { +// this.setPersistent(mode==DeliveryMode.PERSISTENT); +// } +// +// public boolean getJMSRedelivered() { +// return this.isRedelivered(); +// } +// +// public void setJMSRedelivered(boolean redelivered) { +// this.setRedelivered(redelivered); +// } +// +// public String getJMSType() { +// return this.getType(); +// } +// +// public void setJMSType(String type) { +// this.setType(type); +// } +// +// public long getJMSExpiration() { +// return this.getExpiration(); +// } +// +// public void setJMSExpiration(long expiration) { +// this.setExpiration(expiration); +// } +// +// public int getJMSPriority() { +// return this.getPriority(); +// } +// +// public void setJMSPriority(int priority) { +// this.setPriority((byte) priority); +// } +// +// public void clearProperties() { +// super.clearProperties(); +// readOnlyProperties = false; +// } +// +// public boolean propertyExists(String name) throws JMSException { +// try { +// return this.getProperties().containsKey(name); +// } catch (IOException e) { +// throw JMSExceptionSupport.create(e); +// } +// } +// +// public Enumeration getPropertyNames() throws JMSException { +// try { +// return new Vector(this.getProperties().keySet()).elements(); +// } catch (IOException e) { +// throw JMSExceptionSupport.create(e); +// } +// } +// +// interface PropertySetter { +// public void set(Message message, Object value) throws MessageFormatException; +// } +// +// static final private HashMap JMS_PROPERTY_SETERS = new HashMap(); +// static { +// JMS_PROPERTY_SETERS.put("JMSXDeliveryCount", new PropertySetter() { +// public void set(Message message, Object value) throws MessageFormatException { +// Integer rc = (Integer)TypeConversionSupport.convert(value, Integer.class); +// if( rc == null ) { +// throw new MessageFormatException("Property JMSXDeliveryCount cannot be set from a "+value.getClass().getName()+"."); +// } +// message.setRedeliveryCounter(rc.intValue()-1); +// } +// }); +// JMS_PROPERTY_SETERS.put("JMSXGroupID", new PropertySetter() { +// public void set(Message message, Object value) throws MessageFormatException { +// String rc = (String)TypeConversionSupport.convert(value, String.class); +// if( rc == null ) { +// throw new MessageFormatException("Property JMSXGroupID cannot be set from a "+value.getClass().getName()+"."); +// } +// message.setGroupID(rc); +// } +// }); +// JMS_PROPERTY_SETERS.put("JMSXGroupSeq", new PropertySetter() { +// public void set(Message message, Object value) throws MessageFormatException { +// Integer rc = (Integer)TypeConversionSupport.convert(value, Integer.class); +// if( rc == null ) { +// throw new MessageFormatException("Property JMSXGroupSeq cannot be set from a "+value.getClass().getName()+"."); +// } +// message.setGroupSequence(rc.intValue()); +// } +// }); +// JMS_PROPERTY_SETERS.put("JMSCorrelationID", new PropertySetter() { +// public void set(Message message, Object value) throws MessageFormatException { +// String rc = (String)TypeConversionSupport.convert(value, String.class); +// if( rc == null ) { +// throw new MessageFormatException("Property JMSCorrelationID cannot be set from a "+value.getClass().getName()+"."); +// } +// ((ActiveMQMessage)message).setJMSCorrelationID(rc); +// } +// }); +// JMS_PROPERTY_SETERS.put("JMSExpiration", new PropertySetter() { +// public void set(Message message, Object value) throws MessageFormatException { +// Long rc = (Long)TypeConversionSupport.convert(value, Long.class); +// if( rc == null ) { +// throw new MessageFormatException("Property JMSExpiration cannot be set from a "+value.getClass().getName()+"."); +// } +// ((ActiveMQMessage)message).setJMSExpiration(rc.longValue()); +// } +// }); +// JMS_PROPERTY_SETERS.put("JMSPriority", new PropertySetter() { +// public void set(Message message, Object value) throws MessageFormatException { +// Integer rc = (Integer)TypeConversionSupport.convert(value, Integer.class); +// if( rc == null ) { +// throw new MessageFormatException("Property JMSPriority cannot be set from a "+value.getClass().getName()+"."); +// } +// ((ActiveMQMessage)message).setJMSPriority(rc.intValue()); +// } +// }); +// JMS_PROPERTY_SETERS.put("JMSRedelivered", new PropertySetter() { +// public void set(Message message, Object value) throws MessageFormatException { +// Boolean rc = (Boolean)TypeConversionSupport.convert(value, Boolean.class); +// if( rc == null ) { +// throw new MessageFormatException("Property JMSRedelivered cannot be set from a "+value.getClass().getName()+"."); +// } +// ((ActiveMQMessage)message).setJMSRedelivered(rc.booleanValue()); +// } +// }); +// JMS_PROPERTY_SETERS.put("JMSReplyTo", new PropertySetter() { +// public void set(Message message, Object value) throws MessageFormatException { +// ActiveMQDestination rc = (ActiveMQDestination)TypeConversionSupport.convert(value, ActiveMQDestination.class); +// if( rc == null ) { +// throw new MessageFormatException("Property JMSReplyTo cannot be set from a "+value.getClass().getName()+"."); +// } +// ((ActiveMQMessage)message).setReplyTo(rc); +// } +// }); +// JMS_PROPERTY_SETERS.put("JMSTimestamp", new PropertySetter() { +// public void set(Message message, Object value) throws MessageFormatException { +// Long rc = (Long)TypeConversionSupport.convert(value, Long.class); +// if( rc == null ) { +// throw new MessageFormatException("Property JMSTimestamp cannot be set from a "+value.getClass().getName()+"."); +// } +// ((ActiveMQMessage)message).setJMSTimestamp(rc.longValue()); +// } +// }); +// JMS_PROPERTY_SETERS.put("JMSType", new PropertySetter() { +// public void set(Message message, Object value) throws MessageFormatException { +// String rc = (String)TypeConversionSupport.convert(value, String.class); +// if( rc == null ) { +// throw new MessageFormatException("Property JMSType cannot be set from a "+value.getClass().getName()+"."); +// } +// ((ActiveMQMessage)message).setJMSType(rc); +// } +// }); +// } +// +// public void setObjectProperty(String name, Object value) throws JMSException { +// checkReadOnlyProperties(); +// if (name == null || name.equals("")) { +// throw new IllegalArgumentException("Property name cannot be empty or null"); +// } +// +// checkValidObject(value); +// PropertySetter setter = (PropertySetter) JMS_PROPERTY_SETERS.get(name); +// +// if( setter != null ) { +// setter.set(this,value); +// } else { +// try { +// this.setProperty(name, value); +// } catch (IOException e) { +// throw JMSExceptionSupport.create(e); +// } +// } +// } +// +// public void setProperties(Map properties) throws JMSException { +// for (Iterator iter = properties.entrySet().iterator(); iter.hasNext();) { +// Map.Entry entry = (Map.Entry) iter.next(); +// +// // Lets use the object property method as we may contain standard extension headers like JMSXGroupID +// setObjectProperty((String) entry.getKey(), entry.getValue()); +// } +// } +// +// +// protected void checkValidObject(Object value) throws MessageFormatException { +// if (!(value instanceof Boolean || value instanceof Byte || value instanceof Short || value instanceof Integer || value instanceof Long +// || value instanceof Float || value instanceof Double || value instanceof Character || value instanceof String || value == null)) { +// +// ActiveMQConnection conn = getConnection(); +// // conn is null if we are in the broker rather than a JMS client +// if (conn == null || conn.isNestedMapAndListEnabled()) { +// if (!(value instanceof Map || value instanceof List)) { +// throw new MessageFormatException("Only objectified primitive objects, String, Map and List types are allowed but was: " + value + " type: " +// + value.getClass()); +// } +// } +// else { +// throw new MessageFormatException("Only objectified primitive objects and String types are allowed but was: " + value + " type: " +// + value.getClass()); +// } +// } +// } +// +// public Object getObjectProperty(String name) throws JMSException { +// if (name == null) { +// throw new NullPointerException("Property name cannot be null"); +// } +// +// // PropertyExpression handles converting message headers to properties. +// PropertyExpression expression = new PropertyExpression(name); +// return expression.evaluate(this); +// } +// +// public boolean getBooleanProperty(String name) throws JMSException { +// Object value = getObjectProperty(name); +// if( value == null ) +// return false; +// Boolean rc = (Boolean)TypeConversionSupport.convert(value, Boolean.class); +// if( rc == null ) { +// throw new MessageFormatException("Property "+name+" was a "+value.getClass().getName()+" and cannot be read as a boolean"); +// } +// return rc.booleanValue(); +// } +// +// public byte getByteProperty(String name) throws JMSException { +// Object value = getObjectProperty(name); +// if( value == null ) +// throw new NumberFormatException("property "+name+" was null"); +// Byte rc = (Byte)TypeConversionSupport.convert(value, Byte.class); +// if( rc == null ) { +// throw new MessageFormatException("Property "+name+" was a "+value.getClass().getName()+" and cannot be read as a byte"); +// } +// return rc.byteValue(); +// } +// +// public short getShortProperty(String name) throws JMSException { +// Object value = getObjectProperty(name); +// if( value == null ) +// throw new NumberFormatException("property "+name+" was null"); +// Short rc = (Short)TypeConversionSupport.convert(value, Short.class); +// if( rc == null ) { +// throw new MessageFormatException("Property "+name+" was a "+value.getClass().getName()+" and cannot be read as a short"); +// } +// return rc.shortValue(); +// } +// +// public int getIntProperty(String name) throws JMSException { +// Object value = getObjectProperty(name); +// if( value == null ) +// throw new NumberFormatException("property "+name+" was null"); +// Integer rc = (Integer)TypeConversionSupport.convert(value, Integer.class); +// if( rc == null ) { +// throw new MessageFormatException("Property "+name+" was a "+value.getClass().getName()+" and cannot be read as an integer"); +// } +// return rc.intValue(); +// } +// +// public long getLongProperty(String name) throws JMSException { +// Object value = getObjectProperty(name); +// if( value == null ) +// throw new NumberFormatException("property "+name+" was null"); +// Long rc = (Long)TypeConversionSupport.convert(value, Long.class); +// if( rc == null ) { +// throw new MessageFormatException("Property "+name+" was a "+value.getClass().getName()+" and cannot be read as a long"); +// } +// return rc.longValue(); +// } +// +// public float getFloatProperty(String name) throws JMSException { +// Object value = getObjectProperty(name); +// if( value == null ) +// throw new NullPointerException("property "+name+" was null"); +// Float rc = (Float)TypeConversionSupport.convert(value, Float.class); +// if( rc == null ) { +// throw new MessageFormatException("Property "+name+" was a "+value.getClass().getName()+" and cannot be read as a float"); +// } +// return rc.floatValue(); +// } +// +// public double getDoubleProperty(String name) throws JMSException { +// Object value = getObjectProperty(name); +// if( value == null ) +// throw new NullPointerException("property "+name+" was null"); +// Double rc = (Double)TypeConversionSupport.convert(value, Double.class); +// if( rc == null ) { +// throw new MessageFormatException("Property "+name+" was a "+value.getClass().getName()+" and cannot be read as a double"); +// } +// return rc.doubleValue(); +// } +// +// public String getStringProperty(String name) throws JMSException { +// Object value = getObjectProperty(name); +// if( value == null ) { +// if (name.equals("JMSXUserID")) { +// value = getUserID(); +// } +// } +// if( value == null ) +// return null; +// String rc = (String)TypeConversionSupport.convert(value, String.class); +// if( rc == null ) { +// throw new MessageFormatException("Property "+name+" was a "+value.getClass().getName()+" and cannot be read as a String"); +// } +// return rc; +// } +// +// public void setBooleanProperty(String name, boolean value) throws JMSException { +// setObjectProperty(name, value ? Boolean.TRUE : Boolean.FALSE); +// } +// +// public void setByteProperty(String name, byte value) throws JMSException { +// setObjectProperty(name, new Byte(value)); +// } +// +// public void setShortProperty(String name, short value) throws JMSException { +// setObjectProperty(name, new Short(value)); +// } +// +// public void setIntProperty(String name, int value) throws JMSException { +// setObjectProperty(name, new Integer(value)); +// } +// +// public void setLongProperty(String name, long value) throws JMSException { +// setObjectProperty(name, new Long(value)); +// } +// +// public void setFloatProperty(String name, float value) throws JMSException { +// setObjectProperty(name, new Float(value)); +// } +// +// public void setDoubleProperty(String name, double value) throws JMSException { +// setObjectProperty(name, new Double(value)); +// } +// +// public void setStringProperty(String name, String value) throws JMSException { +// setObjectProperty(name, value); +// } +// +// +// private void checkReadOnlyProperties() throws MessageNotWriteableException { +// if (readOnlyProperties) { +// throw new MessageNotWriteableException("Message properties are read-only"); +// } +// } +// +// protected void checkReadOnlyBody() throws MessageNotWriteableException { +// if (readOnlyBody) { +// throw new MessageNotWriteableException("Message body is read-only"); +// } +// } +// +// public boolean isExpired() { +// long expireTime = this.getExpiration(); +// if (expireTime > 0 && System.currentTimeMillis() > expireTime) { +// return true; +// } +// return false; +// } +// +// public Callback getAcknowledgeCallback() { +// return acknowledgeCallback; +// } +// +// public void setAcknowledgeCallback(Callback acknowledgeCallback) { +// this.acknowledgeCallback = acknowledgeCallback; +// } +// +// /** +// * Send operation event listener. Used to get the message ready to be sent. +// */ +// public void onSend() { +// setReadOnlyBody(true); +// setReadOnlyProperties(true); +// } +// +// +// public Response visit(CommandVisitor visitor) throws Exception { +// return visitor.processMessage( this ); +// } +//} +// Propchange: incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/ActiveMQMessage.h ------------------------------------------------------------------------------ svn:eol-style = native Added: incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/ActiveMQObjectMessage.cpp URL: http://svn.apache.org/viewvc/incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/ActiveMQObjectMessage.cpp?view=auto&rev=452053 ============================================================================== --- incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/ActiveMQObjectMessage.cpp (added) +++ incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/ActiveMQObjectMessage.cpp Mon Oct 2 07:30:10 2006 @@ -0,0 +1,50 @@ +/* + * Licensed to the Apache Software Foundation (ASF) under one or more + * contributor license agreements. See the NOTICE file distributed with + * this work for additional information regarding copyright ownership. + * The ASF licenses this file to You under the Apache License, Version 2.0 + * (the "License"); you may not use this file except in compliance with + * the License. You may obtain a copy of the License at + * + * http://www.apache.org/licenses/LICENSE-2.0 + * + * Unless required by applicable law or agreed to in writing, software + * distributed under the License is distributed on an "AS IS" BASIS, + * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. + * See the License for the specific language governing permissions and + * limitations under the License. + */ +#include + +using namespace std; +using namespace activemq; +using namespace activemq::connector; +using namespace activemq::connector::openwire; +using namespace activemq::connector::openwire::commands; + +/* + * + * Command and marshalling code for OpenWire format for ActiveMQObjectMessage + * + * + * NOTE!: This file is autogenerated - do not modify! + * if you need to make a change, please see the Java Classes in the + * activemq-core module + * + */ +//////////////////////////////////////////////////////////////////////////////// +ActiveMQObjectMessage::ActiveMQObjectMessage() +{ +} + +//////////////////////////////////////////////////////////////////////////////// +ActiveMQObjectMessage::~ActiveMQObjectMessage() +{ +} + +//////////////////////////////////////////////////////////////////////////////// +unsigned char ActiveMQObjectMessage::getDataStructureType() const +{ + return ActiveMQObjectMessage::ID_ACTIVEMQOBJECTMESSAGE; +} + Propchange: incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/ActiveMQObjectMessage.cpp ------------------------------------------------------------------------------ svn:eol-style = native Added: incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/ActiveMQObjectMessage.h URL: http://svn.apache.org/viewvc/incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/ActiveMQObjectMessage.h?view=auto&rev=452053 ============================================================================== --- incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/ActiveMQObjectMessage.h (added) +++ incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/ActiveMQObjectMessage.h Mon Oct 2 07:30:10 2006 @@ -0,0 +1,65 @@ +/* + * Licensed to the Apache Software Foundation (ASF) under one or more + * contributor license agreements. See the NOTICE file distributed with + * this work for additional information regarding copyright ownership. + * The ASF licenses this file to You under the Apache License, Version 2.0 + * (the "License"); you may not use this file except in compliance with + * the License. You may obtain a copy of the License at + * + * http://www.apache.org/licenses/LICENSE-2.0 + * + * Unless required by applicable law or agreed to in writing, software + * distributed under the License is distributed on an "AS IS" BASIS, + * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. + * See the License for the specific language governing permissions and + * limitations under the License. + */ + +#ifndef _ACTIVEMQ_CONNECTOR_OPENWIRE_COMMANDS_ACTIVEMQOBJECTMESSAGE_H_ +#define _ACTIVEMQ_CONNECTOR_OPENWIRE_COMMANDS_ACTIVEMQOBJECTMESSAGE_H_ + +// Turn off warning message for ignored exception specification +#ifdef _MSC_VER +#pragma warning( disable : 4290 ) +#endif + +#include +#include +#include + +namespace activemq{ +namespace connector{ +namespace openwire{ +namespace commands{ + + /* + * + * Command and marshalling code for OpenWire format for ${className} + * + * + * NOTE!: This file is autogenerated - do not modify! + * if you need to make a change, please see the Java Classes + * in the activemq-openwire-generator module + * + */ + class ActiveMQObjectMessage : public ActiveMQMessage + { + protected: + + + public: + + const static unsigned char ID_ACTIVEMQOBJECTMESSAGE = 26; + + public: + + ActiveMQObjectMessage(); + virtual ~ActiveMQObjectMessage(); + + virtual unsigned char getDataStructureType() const; + }; + +}}}} + +#endif /*_ACTIVEMQ_CONNECTOR_OPENWIRE_COMMANDS_ACTIVEMQOBJECTMESSAGE_H_*/ + Propchange: incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/ActiveMQObjectMessage.h ------------------------------------------------------------------------------ svn:eol-style = native Added: incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/ActiveMQQueue.cpp URL: http://svn.apache.org/viewvc/incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/ActiveMQQueue.cpp?view=auto&rev=452053 ============================================================================== --- incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/ActiveMQQueue.cpp (added) +++ incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/ActiveMQQueue.cpp Mon Oct 2 07:30:10 2006 @@ -0,0 +1,50 @@ +/* + * Licensed to the Apache Software Foundation (ASF) under one or more + * contributor license agreements. See the NOTICE file distributed with + * this work for additional information regarding copyright ownership. + * The ASF licenses this file to You under the Apache License, Version 2.0 + * (the "License"); you may not use this file except in compliance with + * the License. You may obtain a copy of the License at + * + * http://www.apache.org/licenses/LICENSE-2.0 + * + * Unless required by applicable law or agreed to in writing, software + * distributed under the License is distributed on an "AS IS" BASIS, + * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. + * See the License for the specific language governing permissions and + * limitations under the License. + */ +#include + +using namespace std; +using namespace activemq; +using namespace activemq::connector; +using namespace activemq::connector::openwire; +using namespace activemq::connector::openwire::commands; + +/* + * + * Command and marshalling code for OpenWire format for ActiveMQQueue + * + * + * NOTE!: This file is autogenerated - do not modify! + * if you need to make a change, please see the Java Classes in the + * activemq-core module + * + */ +//////////////////////////////////////////////////////////////////////////////// +ActiveMQQueue::ActiveMQQueue() +{ +} + +//////////////////////////////////////////////////////////////////////////////// +ActiveMQQueue::~ActiveMQQueue() +{ +} + +//////////////////////////////////////////////////////////////////////////////// +unsigned char ActiveMQQueue::getDataStructureType() const +{ + return ActiveMQQueue::ID_ACTIVEMQQUEUE; +} + Propchange: incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/ActiveMQQueue.cpp ------------------------------------------------------------------------------ svn:eol-style = native Added: incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/ActiveMQQueue.h URL: http://svn.apache.org/viewvc/incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/ActiveMQQueue.h?view=auto&rev=452053 ============================================================================== --- incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/ActiveMQQueue.h (added) +++ incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/ActiveMQQueue.h Mon Oct 2 07:30:10 2006 @@ -0,0 +1,65 @@ +/* + * Licensed to the Apache Software Foundation (ASF) under one or more + * contributor license agreements. See the NOTICE file distributed with + * this work for additional information regarding copyright ownership. + * The ASF licenses this file to You under the Apache License, Version 2.0 + * (the "License"); you may not use this file except in compliance with + * the License. You may obtain a copy of the License at + * + * http://www.apache.org/licenses/LICENSE-2.0 + * + * Unless required by applicable law or agreed to in writing, software + * distributed under the License is distributed on an "AS IS" BASIS, + * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. + * See the License for the specific language governing permissions and + * limitations under the License. + */ + +#ifndef _ACTIVEMQ_CONNECTOR_OPENWIRE_COMMANDS_ACTIVEMQQUEUE_H_ +#define _ACTIVEMQ_CONNECTOR_OPENWIRE_COMMANDS_ACTIVEMQQUEUE_H_ + +// Turn off warning message for ignored exception specification +#ifdef _MSC_VER +#pragma warning( disable : 4290 ) +#endif + +#include +#include +#include + +namespace activemq{ +namespace connector{ +namespace openwire{ +namespace commands{ + + /* + * + * Command and marshalling code for OpenWire format for ${className} + * + * + * NOTE!: This file is autogenerated - do not modify! + * if you need to make a change, please see the Java Classes + * in the activemq-openwire-generator module + * + */ + class ActiveMQQueue : public ActiveMQDestination + { + protected: + + + public: + + const static unsigned char ID_ACTIVEMQQUEUE = 100; + + public: + + ActiveMQQueue(); + virtual ~ActiveMQQueue(); + + virtual unsigned char getDataStructureType() const; + }; + +}}}} + +#endif /*_ACTIVEMQ_CONNECTOR_OPENWIRE_COMMANDS_ACTIVEMQQUEUE_H_*/ + Propchange: incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/ActiveMQQueue.h ------------------------------------------------------------------------------ svn:eol-style = native Added: incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/ActiveMQStreamMessage.cpp URL: http://svn.apache.org/viewvc/incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/ActiveMQStreamMessage.cpp?view=auto&rev=452053 ============================================================================== --- incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/ActiveMQStreamMessage.cpp (added) +++ incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/ActiveMQStreamMessage.cpp Mon Oct 2 07:30:10 2006 @@ -0,0 +1,50 @@ +/* + * Licensed to the Apache Software Foundation (ASF) under one or more + * contributor license agreements. See the NOTICE file distributed with + * this work for additional information regarding copyright ownership. + * The ASF licenses this file to You under the Apache License, Version 2.0 + * (the "License"); you may not use this file except in compliance with + * the License. You may obtain a copy of the License at + * + * http://www.apache.org/licenses/LICENSE-2.0 + * + * Unless required by applicable law or agreed to in writing, software + * distributed under the License is distributed on an "AS IS" BASIS, + * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. + * See the License for the specific language governing permissions and + * limitations under the License. + */ +#include + +using namespace std; +using namespace activemq; +using namespace activemq::connector; +using namespace activemq::connector::openwire; +using namespace activemq::connector::openwire::commands; + +/* + * + * Command and marshalling code for OpenWire format for ActiveMQStreamMessage + * + * + * NOTE!: This file is autogenerated - do not modify! + * if you need to make a change, please see the Java Classes in the + * activemq-core module + * + */ +//////////////////////////////////////////////////////////////////////////////// +ActiveMQStreamMessage::ActiveMQStreamMessage() +{ +} + +//////////////////////////////////////////////////////////////////////////////// +ActiveMQStreamMessage::~ActiveMQStreamMessage() +{ +} + +//////////////////////////////////////////////////////////////////////////////// +unsigned char ActiveMQStreamMessage::getDataStructureType() const +{ + return ActiveMQStreamMessage::ID_ACTIVEMQSTREAMMESSAGE; +} + Propchange: incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/ActiveMQStreamMessage.cpp ------------------------------------------------------------------------------ svn:eol-style = native Added: incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/ActiveMQStreamMessage.h URL: http://svn.apache.org/viewvc/incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/ActiveMQStreamMessage.h?view=auto&rev=452053 ============================================================================== --- incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/ActiveMQStreamMessage.h (added) +++ incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/ActiveMQStreamMessage.h Mon Oct 2 07:30:10 2006 @@ -0,0 +1,65 @@ +/* + * Licensed to the Apache Software Foundation (ASF) under one or more + * contributor license agreements. See the NOTICE file distributed with + * this work for additional information regarding copyright ownership. + * The ASF licenses this file to You under the Apache License, Version 2.0 + * (the "License"); you may not use this file except in compliance with + * the License. You may obtain a copy of the License at + * + * http://www.apache.org/licenses/LICENSE-2.0 + * + * Unless required by applicable law or agreed to in writing, software + * distributed under the License is distributed on an "AS IS" BASIS, + * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. + * See the License for the specific language governing permissions and + * limitations under the License. + */ + +#ifndef _ACTIVEMQ_CONNECTOR_OPENWIRE_COMMANDS_ACTIVEMQSTREAMMESSAGE_H_ +#define _ACTIVEMQ_CONNECTOR_OPENWIRE_COMMANDS_ACTIVEMQSTREAMMESSAGE_H_ + +// Turn off warning message for ignored exception specification +#ifdef _MSC_VER +#pragma warning( disable : 4290 ) +#endif + +#include +#include +#include + +namespace activemq{ +namespace connector{ +namespace openwire{ +namespace commands{ + + /* + * + * Command and marshalling code for OpenWire format for ${className} + * + * + * NOTE!: This file is autogenerated - do not modify! + * if you need to make a change, please see the Java Classes + * in the activemq-openwire-generator module + * + */ + class ActiveMQStreamMessage : public ActiveMQMessage + { + protected: + + + public: + + const static unsigned char ID_ACTIVEMQSTREAMMESSAGE = 27; + + public: + + ActiveMQStreamMessage(); + virtual ~ActiveMQStreamMessage(); + + virtual unsigned char getDataStructureType() const; + }; + +}}}} + +#endif /*_ACTIVEMQ_CONNECTOR_OPENWIRE_COMMANDS_ACTIVEMQSTREAMMESSAGE_H_*/ + Propchange: incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/ActiveMQStreamMessage.h ------------------------------------------------------------------------------ svn:eol-style = native Added: incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/ActiveMQTempDestination.cpp URL: http://svn.apache.org/viewvc/incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/ActiveMQTempDestination.cpp?view=auto&rev=452053 ============================================================================== --- incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/ActiveMQTempDestination.cpp (added) +++ incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/ActiveMQTempDestination.cpp Mon Oct 2 07:30:10 2006 @@ -0,0 +1,50 @@ +/* + * Licensed to the Apache Software Foundation (ASF) under one or more + * contributor license agreements. See the NOTICE file distributed with + * this work for additional information regarding copyright ownership. + * The ASF licenses this file to You under the Apache License, Version 2.0 + * (the "License"); you may not use this file except in compliance with + * the License. You may obtain a copy of the License at + * + * http://www.apache.org/licenses/LICENSE-2.0 + * + * Unless required by applicable law or agreed to in writing, software + * distributed under the License is distributed on an "AS IS" BASIS, + * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. + * See the License for the specific language governing permissions and + * limitations under the License. + */ +#include + +using namespace std; +using namespace activemq; +using namespace activemq::connector; +using namespace activemq::connector::openwire; +using namespace activemq::connector::openwire::commands; + +/* + * + * Command and marshalling code for OpenWire format for ActiveMQTempDestination + * + * + * NOTE!: This file is autogenerated - do not modify! + * if you need to make a change, please see the Java Classes in the + * activemq-core module + * + */ +//////////////////////////////////////////////////////////////////////////////// +ActiveMQTempDestination::ActiveMQTempDestination() +{ +} + +//////////////////////////////////////////////////////////////////////////////// +ActiveMQTempDestination::~ActiveMQTempDestination() +{ +} + +//////////////////////////////////////////////////////////////////////////////// +unsigned char ActiveMQTempDestination::getDataStructureType() const +{ + return ActiveMQTempDestination::ID_ACTIVEMQTEMPDESTINATION; +} + Propchange: incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/ActiveMQTempDestination.cpp ------------------------------------------------------------------------------ svn:eol-style = native Added: incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/ActiveMQTempDestination.h URL: http://svn.apache.org/viewvc/incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/ActiveMQTempDestination.h?view=auto&rev=452053 ============================================================================== --- incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/ActiveMQTempDestination.h (added) +++ incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/ActiveMQTempDestination.h Mon Oct 2 07:30:10 2006 @@ -0,0 +1,65 @@ +/* + * Licensed to the Apache Software Foundation (ASF) under one or more + * contributor license agreements. See the NOTICE file distributed with + * this work for additional information regarding copyright ownership. + * The ASF licenses this file to You under the Apache License, Version 2.0 + * (the "License"); you may not use this file except in compliance with + * the License. You may obtain a copy of the License at + * + * http://www.apache.org/licenses/LICENSE-2.0 + * + * Unless required by applicable law or agreed to in writing, software + * distributed under the License is distributed on an "AS IS" BASIS, + * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. + * See the License for the specific language governing permissions and + * limitations under the License. + */ + +#ifndef _ACTIVEMQ_CONNECTOR_OPENWIRE_COMMANDS_ACTIVEMQTEMPDESTINATION_H_ +#define _ACTIVEMQ_CONNECTOR_OPENWIRE_COMMANDS_ACTIVEMQTEMPDESTINATION_H_ + +// Turn off warning message for ignored exception specification +#ifdef _MSC_VER +#pragma warning( disable : 4290 ) +#endif + +#include +#include +#include + +namespace activemq{ +namespace connector{ +namespace openwire{ +namespace commands{ + + /* + * + * Command and marshalling code for OpenWire format for ${className} + * + * + * NOTE!: This file is autogenerated - do not modify! + * if you need to make a change, please see the Java Classes + * in the activemq-openwire-generator module + * + */ + class ActiveMQTempDestination : public ActiveMQDestination + { + protected: + + + public: + + const static unsigned char ID_ACTIVEMQTEMPDESTINATION = 0; + + public: + + ActiveMQTempDestination(); + virtual ~ActiveMQTempDestination(); + + virtual unsigned char getDataStructureType() const; + }; + +}}}} + +#endif /*_ACTIVEMQ_CONNECTOR_OPENWIRE_COMMANDS_ACTIVEMQTEMPDESTINATION_H_*/ + Propchange: incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/ActiveMQTempDestination.h ------------------------------------------------------------------------------ svn:eol-style = native Added: incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/ActiveMQTempQueue.cpp URL: http://svn.apache.org/viewvc/incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/ActiveMQTempQueue.cpp?view=auto&rev=452053 ============================================================================== --- incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/ActiveMQTempQueue.cpp (added) +++ incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/ActiveMQTempQueue.cpp Mon Oct 2 07:30:10 2006 @@ -0,0 +1,50 @@ +/* + * Licensed to the Apache Software Foundation (ASF) under one or more + * contributor license agreements. See the NOTICE file distributed with + * this work for additional information regarding copyright ownership. + * The ASF licenses this file to You under the Apache License, Version 2.0 + * (the "License"); you may not use this file except in compliance with + * the License. You may obtain a copy of the License at + * + * http://www.apache.org/licenses/LICENSE-2.0 + * + * Unless required by applicable law or agreed to in writing, software + * distributed under the License is distributed on an "AS IS" BASIS, + * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. + * See the License for the specific language governing permissions and + * limitations under the License. + */ +#include + +using namespace std; +using namespace activemq; +using namespace activemq::connector; +using namespace activemq::connector::openwire; +using namespace activemq::connector::openwire::commands; + +/* + * + * Command and marshalling code for OpenWire format for ActiveMQTempQueue + * + * + * NOTE!: This file is autogenerated - do not modify! + * if you need to make a change, please see the Java Classes in the + * activemq-core module + * + */ +//////////////////////////////////////////////////////////////////////////////// +ActiveMQTempQueue::ActiveMQTempQueue() +{ +} + +//////////////////////////////////////////////////////////////////////////////// +ActiveMQTempQueue::~ActiveMQTempQueue() +{ +} + +//////////////////////////////////////////////////////////////////////////////// +unsigned char ActiveMQTempQueue::getDataStructureType() const +{ + return ActiveMQTempQueue::ID_ACTIVEMQTEMPQUEUE; +} + Propchange: incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/ActiveMQTempQueue.cpp ------------------------------------------------------------------------------ svn:eol-style = native Added: incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/ActiveMQTempQueue.h URL: http://svn.apache.org/viewvc/incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/ActiveMQTempQueue.h?view=auto&rev=452053 ============================================================================== --- incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/ActiveMQTempQueue.h (added) +++ incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/ActiveMQTempQueue.h Mon Oct 2 07:30:10 2006 @@ -0,0 +1,65 @@ +/* + * Licensed to the Apache Software Foundation (ASF) under one or more + * contributor license agreements. See the NOTICE file distributed with + * this work for additional information regarding copyright ownership. + * The ASF licenses this file to You under the Apache License, Version 2.0 + * (the "License"); you may not use this file except in compliance with + * the License. You may obtain a copy of the License at + * + * http://www.apache.org/licenses/LICENSE-2.0 + * + * Unless required by applicable law or agreed to in writing, software + * distributed under the License is distributed on an "AS IS" BASIS, + * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. + * See the License for the specific language governing permissions and + * limitations under the License. + */ + +#ifndef _ACTIVEMQ_CONNECTOR_OPENWIRE_COMMANDS_ACTIVEMQTEMPQUEUE_H_ +#define _ACTIVEMQ_CONNECTOR_OPENWIRE_COMMANDS_ACTIVEMQTEMPQUEUE_H_ + +// Turn off warning message for ignored exception specification +#ifdef _MSC_VER +#pragma warning( disable : 4290 ) +#endif + +#include +#include +#include + +namespace activemq{ +namespace connector{ +namespace openwire{ +namespace commands{ + + /* + * + * Command and marshalling code for OpenWire format for ${className} + * + * + * NOTE!: This file is autogenerated - do not modify! + * if you need to make a change, please see the Java Classes + * in the activemq-openwire-generator module + * + */ + class ActiveMQTempQueue : public ActiveMQTempDestination + { + protected: + + + public: + + const static unsigned char ID_ACTIVEMQTEMPQUEUE = 102; + + public: + + ActiveMQTempQueue(); + virtual ~ActiveMQTempQueue(); + + virtual unsigned char getDataStructureType() const; + }; + +}}}} + +#endif /*_ACTIVEMQ_CONNECTOR_OPENWIRE_COMMANDS_ACTIVEMQTEMPQUEUE_H_*/ + Propchange: incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/ActiveMQTempQueue.h ------------------------------------------------------------------------------ svn:eol-style = native Added: incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/ActiveMQTempTopic.cpp URL: http://svn.apache.org/viewvc/incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/ActiveMQTempTopic.cpp?view=auto&rev=452053 ============================================================================== --- incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/ActiveMQTempTopic.cpp (added) +++ incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/ActiveMQTempTopic.cpp Mon Oct 2 07:30:10 2006 @@ -0,0 +1,50 @@ +/* + * Licensed to the Apache Software Foundation (ASF) under one or more + * contributor license agreements. See the NOTICE file distributed with + * this work for additional information regarding copyright ownership. + * The ASF licenses this file to You under the Apache License, Version 2.0 + * (the "License"); you may not use this file except in compliance with + * the License. You may obtain a copy of the License at + * + * http://www.apache.org/licenses/LICENSE-2.0 + * + * Unless required by applicable law or agreed to in writing, software + * distributed under the License is distributed on an "AS IS" BASIS, + * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. + * See the License for the specific language governing permissions and + * limitations under the License. + */ +#include + +using namespace std; +using namespace activemq; +using namespace activemq::connector; +using namespace activemq::connector::openwire; +using namespace activemq::connector::openwire::commands; + +/* + * + * Command and marshalling code for OpenWire format for ActiveMQTempTopic + * + * + * NOTE!: This file is autogenerated - do not modify! + * if you need to make a change, please see the Java Classes in the + * activemq-core module + * + */ +//////////////////////////////////////////////////////////////////////////////// +ActiveMQTempTopic::ActiveMQTempTopic() +{ +} + +//////////////////////////////////////////////////////////////////////////////// +ActiveMQTempTopic::~ActiveMQTempTopic() +{ +} + +//////////////////////////////////////////////////////////////////////////////// +unsigned char ActiveMQTempTopic::getDataStructureType() const +{ + return ActiveMQTempTopic::ID_ACTIVEMQTEMPTOPIC; +} + Propchange: incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/ActiveMQTempTopic.cpp ------------------------------------------------------------------------------ svn:eol-style = native Added: incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/ActiveMQTempTopic.h URL: http://svn.apache.org/viewvc/incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/ActiveMQTempTopic.h?view=auto&rev=452053 ============================================================================== --- incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/ActiveMQTempTopic.h (added) +++ incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/ActiveMQTempTopic.h Mon Oct 2 07:30:10 2006 @@ -0,0 +1,65 @@ +/* + * Licensed to the Apache Software Foundation (ASF) under one or more + * contributor license agreements. See the NOTICE file distributed with + * this work for additional information regarding copyright ownership. + * The ASF licenses this file to You under the Apache License, Version 2.0 + * (the "License"); you may not use this file except in compliance with + * the License. You may obtain a copy of the License at + * + * http://www.apache.org/licenses/LICENSE-2.0 + * + * Unless required by applicable law or agreed to in writing, software + * distributed under the License is distributed on an "AS IS" BASIS, + * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. + * See the License for the specific language governing permissions and + * limitations under the License. + */ + +#ifndef _ACTIVEMQ_CONNECTOR_OPENWIRE_COMMANDS_ACTIVEMQTEMPTOPIC_H_ +#define _ACTIVEMQ_CONNECTOR_OPENWIRE_COMMANDS_ACTIVEMQTEMPTOPIC_H_ + +// Turn off warning message for ignored exception specification +#ifdef _MSC_VER +#pragma warning( disable : 4290 ) +#endif + +#include +#include +#include + +namespace activemq{ +namespace connector{ +namespace openwire{ +namespace commands{ + + /* + * + * Command and marshalling code for OpenWire format for ${className} + * + * + * NOTE!: This file is autogenerated - do not modify! + * if you need to make a change, please see the Java Classes + * in the activemq-openwire-generator module + * + */ + class ActiveMQTempTopic : public ActiveMQTempDestination + { + protected: + + + public: + + const static unsigned char ID_ACTIVEMQTEMPTOPIC = 103; + + public: + + ActiveMQTempTopic(); + virtual ~ActiveMQTempTopic(); + + virtual unsigned char getDataStructureType() const; + }; + +}}}} + +#endif /*_ACTIVEMQ_CONNECTOR_OPENWIRE_COMMANDS_ACTIVEMQTEMPTOPIC_H_*/ + Propchange: incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/ActiveMQTempTopic.h ------------------------------------------------------------------------------ svn:eol-style = native Added: incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/ActiveMQTextMessage.cpp URL: http://svn.apache.org/viewvc/incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/ActiveMQTextMessage.cpp?view=auto&rev=452053 ============================================================================== --- incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/ActiveMQTextMessage.cpp (added) +++ incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/ActiveMQTextMessage.cpp Mon Oct 2 07:30:10 2006 @@ -0,0 +1,50 @@ +/* + * Licensed to the Apache Software Foundation (ASF) under one or more + * contributor license agreements. See the NOTICE file distributed with + * this work for additional information regarding copyright ownership. + * The ASF licenses this file to You under the Apache License, Version 2.0 + * (the "License"); you may not use this file except in compliance with + * the License. You may obtain a copy of the License at + * + * http://www.apache.org/licenses/LICENSE-2.0 + * + * Unless required by applicable law or agreed to in writing, software + * distributed under the License is distributed on an "AS IS" BASIS, + * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. + * See the License for the specific language governing permissions and + * limitations under the License. + */ +#include + +using namespace std; +using namespace activemq; +using namespace activemq::connector; +using namespace activemq::connector::openwire; +using namespace activemq::connector::openwire::commands; + +/* + * + * Command and marshalling code for OpenWire format for ActiveMQTextMessage + * + * + * NOTE!: This file is autogenerated - do not modify! + * if you need to make a change, please see the Java Classes in the + * activemq-core module + * + */ +//////////////////////////////////////////////////////////////////////////////// +ActiveMQTextMessage::ActiveMQTextMessage() +{ +} + +//////////////////////////////////////////////////////////////////////////////// +ActiveMQTextMessage::~ActiveMQTextMessage() +{ +} + +//////////////////////////////////////////////////////////////////////////////// +unsigned char ActiveMQTextMessage::getDataStructureType() const +{ + return ActiveMQTextMessage::ID_ACTIVEMQTEXTMESSAGE; +} + Propchange: incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/ActiveMQTextMessage.cpp ------------------------------------------------------------------------------ svn:eol-style = native Added: incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/ActiveMQTextMessage.h URL: http://svn.apache.org/viewvc/incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/ActiveMQTextMessage.h?view=auto&rev=452053 ============================================================================== --- incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/ActiveMQTextMessage.h (added) +++ incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/ActiveMQTextMessage.h Mon Oct 2 07:30:10 2006 @@ -0,0 +1,65 @@ +/* + * Licensed to the Apache Software Foundation (ASF) under one or more + * contributor license agreements. See the NOTICE file distributed with + * this work for additional information regarding copyright ownership. + * The ASF licenses this file to You under the Apache License, Version 2.0 + * (the "License"); you may not use this file except in compliance with + * the License. You may obtain a copy of the License at + * + * http://www.apache.org/licenses/LICENSE-2.0 + * + * Unless required by applicable law or agreed to in writing, software + * distributed under the License is distributed on an "AS IS" BASIS, + * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. + * See the License for the specific language governing permissions and + * limitations under the License. + */ + +#ifndef _ACTIVEMQ_CONNECTOR_OPENWIRE_COMMANDS_ACTIVEMQTEXTMESSAGE_H_ +#define _ACTIVEMQ_CONNECTOR_OPENWIRE_COMMANDS_ACTIVEMQTEXTMESSAGE_H_ + +// Turn off warning message for ignored exception specification +#ifdef _MSC_VER +#pragma warning( disable : 4290 ) +#endif + +#include +#include +#include + +namespace activemq{ +namespace connector{ +namespace openwire{ +namespace commands{ + + /* + * + * Command and marshalling code for OpenWire format for ${className} + * + * + * NOTE!: This file is autogenerated - do not modify! + * if you need to make a change, please see the Java Classes + * in the activemq-openwire-generator module + * + */ + class ActiveMQTextMessage : public ActiveMQMessage + { + protected: + + + public: + + const static unsigned char ID_ACTIVEMQTEXTMESSAGE = 28; + + public: + + ActiveMQTextMessage(); + virtual ~ActiveMQTextMessage(); + + virtual unsigned char getDataStructureType() const; + }; + +}}}} + +#endif /*_ACTIVEMQ_CONNECTOR_OPENWIRE_COMMANDS_ACTIVEMQTEXTMESSAGE_H_*/ + Propchange: incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/ActiveMQTextMessage.h ------------------------------------------------------------------------------ svn:eol-style = native Added: incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/ActiveMQTopic.cpp URL: http://svn.apache.org/viewvc/incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/ActiveMQTopic.cpp?view=auto&rev=452053 ============================================================================== --- incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/ActiveMQTopic.cpp (added) +++ incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/ActiveMQTopic.cpp Mon Oct 2 07:30:10 2006 @@ -0,0 +1,50 @@ +/* + * Licensed to the Apache Software Foundation (ASF) under one or more + * contributor license agreements. See the NOTICE file distributed with + * this work for additional information regarding copyright ownership. + * The ASF licenses this file to You under the Apache License, Version 2.0 + * (the "License"); you may not use this file except in compliance with + * the License. You may obtain a copy of the License at + * + * http://www.apache.org/licenses/LICENSE-2.0 + * + * Unless required by applicable law or agreed to in writing, software + * distributed under the License is distributed on an "AS IS" BASIS, + * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. + * See the License for the specific language governing permissions and + * limitations under the License. + */ +#include + +using namespace std; +using namespace activemq; +using namespace activemq::connector; +using namespace activemq::connector::openwire; +using namespace activemq::connector::openwire::commands; + +/* + * + * Command and marshalling code for OpenWire format for ActiveMQTopic + * + * + * NOTE!: This file is autogenerated - do not modify! + * if you need to make a change, please see the Java Classes in the + * activemq-core module + * + */ +//////////////////////////////////////////////////////////////////////////////// +ActiveMQTopic::ActiveMQTopic() +{ +} + +//////////////////////////////////////////////////////////////////////////////// +ActiveMQTopic::~ActiveMQTopic() +{ +} + +//////////////////////////////////////////////////////////////////////////////// +unsigned char ActiveMQTopic::getDataStructureType() const +{ + return ActiveMQTopic::ID_ACTIVEMQTOPIC; +} + Propchange: incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/ActiveMQTopic.cpp ------------------------------------------------------------------------------ svn:eol-style = native Added: incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/ActiveMQTopic.h URL: http://svn.apache.org/viewvc/incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/ActiveMQTopic.h?view=auto&rev=452053 ============================================================================== --- incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/ActiveMQTopic.h (added) +++ incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/ActiveMQTopic.h Mon Oct 2 07:30:10 2006 @@ -0,0 +1,65 @@ +/* + * Licensed to the Apache Software Foundation (ASF) under one or more + * contributor license agreements. See the NOTICE file distributed with + * this work for additional information regarding copyright ownership. + * The ASF licenses this file to You under the Apache License, Version 2.0 + * (the "License"); you may not use this file except in compliance with + * the License. You may obtain a copy of the License at + * + * http://www.apache.org/licenses/LICENSE-2.0 + * + * Unless required by applicable law or agreed to in writing, software + * distributed under the License is distributed on an "AS IS" BASIS, + * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. + * See the License for the specific language governing permissions and + * limitations under the License. + */ + +#ifndef _ACTIVEMQ_CONNECTOR_OPENWIRE_COMMANDS_ACTIVEMQTOPIC_H_ +#define _ACTIVEMQ_CONNECTOR_OPENWIRE_COMMANDS_ACTIVEMQTOPIC_H_ + +// Turn off warning message for ignored exception specification +#ifdef _MSC_VER +#pragma warning( disable : 4290 ) +#endif + +#include +#include +#include + +namespace activemq{ +namespace connector{ +namespace openwire{ +namespace commands{ + + /* + * + * Command and marshalling code for OpenWire format for ${className} + * + * + * NOTE!: This file is autogenerated - do not modify! + * if you need to make a change, please see the Java Classes + * in the activemq-openwire-generator module + * + */ + class ActiveMQTopic : public ActiveMQDestination + { + protected: + + + public: + + const static unsigned char ID_ACTIVEMQTOPIC = 101; + + public: + + ActiveMQTopic(); + virtual ~ActiveMQTopic(); + + virtual unsigned char getDataStructureType() const; + }; + +}}}} + +#endif /*_ACTIVEMQ_CONNECTOR_OPENWIRE_COMMANDS_ACTIVEMQTOPIC_H_*/ + Propchange: incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/ActiveMQTopic.h ------------------------------------------------------------------------------ svn:eol-style = native Added: incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/BaseCommand.cpp URL: http://svn.apache.org/viewvc/incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/BaseCommand.cpp?view=auto&rev=452053 ============================================================================== --- incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/BaseCommand.cpp (added) +++ incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/BaseCommand.cpp Mon Oct 2 07:30:10 2006 @@ -0,0 +1,82 @@ +/* + * Licensed to the Apache Software Foundation (ASF) under one or more + * contributor license agreements. See the NOTICE file distributed with + * this work for additional information regarding copyright ownership. + * The ASF licenses this file to You under the Apache License, Version 2.0 + * (the "License"); you may not use this file except in compliance with + * the License. You may obtain a copy of the License at + * + * http://www.apache.org/licenses/LICENSE-2.0 + * + * Unless required by applicable law or agreed to in writing, software + * distributed under the License is distributed on an "AS IS" BASIS, + * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. + * See the License for the specific language governing permissions and + * limitations under the License. + */ +#include + +using namespace std; +using namespace activemq; +using namespace activemq::connector; +using namespace activemq::connector::openwire; +using namespace activemq::connector::openwire::commands; + +/* + * + * Command and marshalling code for OpenWire format for BaseCommand + * + * + * NOTE!: This file is autogenerated - do not modify! + * if you need to make a change, please see the Java Classes in the + * activemq-core module + * + */ +//////////////////////////////////////////////////////////////////////////////// +BaseCommand::BaseCommand() +{ + this->commandId = 0; + this->responseRequired = false; +} + +//////////////////////////////////////////////////////////////////////////////// +BaseCommand::~BaseCommand() +{ +} + +//////////////////////////////////////////////////////////////////////////////// +unsigned char BaseCommand::getDataStructureType() const +{ + return BaseCommand::ID_BASECOMMAND; +} + +//////////////////////////////////////////////////////////////////////////////// +const int BaseCommand::getCommandId() const { + return commandId; +} + +//////////////////////////////////////////////////////////////////////////////// +int BaseCommand::getCommandId() { + return commandId; +} + +//////////////////////////////////////////////////////////////////////////////// +void BaseCommand::setCommandId(int commandId ) { + this->commandId = commandId; +} + +//////////////////////////////////////////////////////////////////////////////// +const bool BaseCommand::getResponseRequired() const { + return responseRequired; +} + +//////////////////////////////////////////////////////////////////////////////// +bool BaseCommand::getResponseRequired() { + return responseRequired; +} + +//////////////////////////////////////////////////////////////////////////////// +void BaseCommand::setResponseRequired(bool responseRequired ) { + this->responseRequired = responseRequired; +} + Propchange: incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/BaseCommand.cpp ------------------------------------------------------------------------------ svn:eol-style = native Added: incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/BaseCommand.h URL: http://svn.apache.org/viewvc/incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/BaseCommand.h?view=auto&rev=452053 ============================================================================== --- incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/BaseCommand.h (added) +++ incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/BaseCommand.h Mon Oct 2 07:30:10 2006 @@ -0,0 +1,75 @@ +/* + * Licensed to the Apache Software Foundation (ASF) under one or more + * contributor license agreements. See the NOTICE file distributed with + * this work for additional information regarding copyright ownership. + * The ASF licenses this file to You under the Apache License, Version 2.0 + * (the "License"); you may not use this file except in compliance with + * the License. You may obtain a copy of the License at + * + * http://www.apache.org/licenses/LICENSE-2.0 + * + * Unless required by applicable law or agreed to in writing, software + * distributed under the License is distributed on an "AS IS" BASIS, + * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. + * See the License for the specific language governing permissions and + * limitations under the License. + */ + +#ifndef _ACTIVEMQ_CONNECTOR_OPENWIRE_COMMANDS_BASECOMMAND_H_ +#define _ACTIVEMQ_CONNECTOR_OPENWIRE_COMMANDS_BASECOMMAND_H_ + +#include + +namespace activemq{ +namespace connector{ +namespace openwire{ +namespace commands{ + + class BaseCommand : transport::Command + { + public: + + virtual ~BaseCommand() {} + + /** + * Sets the Command Id of this Message + * @param id Command Id + */ + virtual void setCommandId( const unsigned int id ) { + this->commandId = id; + } + + /** + * Gets the Command Id of this Message + * @return Command Id + */ + virtual unsigned int getCommandId() const { + return commandId; + } + + /** + * Set if this Message requires a Response + * @param required true if response is required + */ + virtual void setResponseRequired( const bool required ) { + this->responseRequired = required; + } + + /** + * Is a Response required for this Command + * @return true if a response is required. + */ + virtual bool isResponseRequired() const { + return responseRequired; + } + + private: + + bool responseRequired; + int commandId; + + }; + +}}}} + +#endif /*_ACTIVEMQ_CONNECTOR_OPENWIRE_COMMANDS_BASECOMMAND_H_*/ Propchange: incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/BaseCommand.h ------------------------------------------------------------------------------ svn:eol-style = native Added: incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/BaseDataStructure.h URL: http://svn.apache.org/viewvc/incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/BaseDataStructure.h?view=auto&rev=452053 ============================================================================== --- incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/BaseDataStructure.h (added) +++ incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/BaseDataStructure.h Mon Oct 2 07:30:10 2006 @@ -0,0 +1,47 @@ +/* + * Licensed to the Apache Software Foundation (ASF) under one or more + * contributor license agreements. See the NOTICE file distributed with + * this work for additional information regarding copyright ownership. + * The ASF licenses this file to You under the Apache License, Version 2.0 + * (the "License"); you may not use this file except in compliance with + * the License. You may obtain a copy of the License at + * + * http://www.apache.org/licenses/LICENSE-2.0 + * + * Unless required by applicable law or agreed to in writing, software + * distributed under the License is distributed on an "AS IS" BASIS, + * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. + * See the License for the specific language governing permissions and + * limitations under the License. + */ + +#ifndef _ACTIVEMQ_CONNECTOR_OPENWIRE_COMMANDS_BASEDATASTRUCTURE_H_ +#define _ACTIVEMQ_CONNECTOR_OPENWIRE_COMMANDS_BASEDATASTRUCTURE_H_ + +#include + +namespace activemq{ +namespace connector{ +namespace openwire{ +namespace commands{ + + class BaseDataStructure : public DataStructure + { + public: + + virtual ~BaseDataStructure() {} + + /** + * Determine if this object is aware of marshalling and should have + * its before and after marshalling methods called. Defaults to false. + * @returns true if aware of marshalling + */ + virtual bool isMarshallAware() const { + return false; + } + + }; + +}}}} + +#endif /*_ACTIVEMQ_CONNECTOR_OPENWIRE_COMMANDS_BASEDATASTRUCTURE_H_*/ Propchange: incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/BaseDataStructure.h ------------------------------------------------------------------------------ svn:eol-style = native Added: incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/BooleanExpression.h URL: http://svn.apache.org/viewvc/incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/BooleanExpression.h?view=auto&rev=452053 ============================================================================== --- incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/BooleanExpression.h (added) +++ incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/BooleanExpression.h Mon Oct 2 07:30:10 2006 @@ -0,0 +1,37 @@ +/* + * Licensed to the Apache Software Foundation (ASF) under one or more + * contributor license agreements. See the NOTICE file distributed with + * this work for additional information regarding copyright ownership. + * The ASF licenses this file to You under the Apache License, Version 2.0 + * (the "License"); you may not use this file except in compliance with + * the License. You may obtain a copy of the License at + * + * http://www.apache.org/licenses/LICENSE-2.0 + * + * Unless required by applicable law or agreed to in writing, software + * distributed under the License is distributed on an "AS IS" BASIS, + * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. + * See the License for the specific language governing permissions and + * limitations under the License. + */ + +#ifndef _ACTIVEMQ_CONNECTOR_OPENWIRE_COMMANDS_BOOLEANEXPRESSION_H_ +#define _ACTIVEMQ_CONNECTOR_OPENWIRE_COMMANDS_BOOLEANEXPRESSION_H_ + +namespace activemq{ +namespace connector{ +namespace openwire{ +namespace commands{ + + class BooleanExpression + { + public: + + BooleanExpression() {} + virtual ~BooleanExpression() {} + + }; + +}}}} + +#endif /*_ACTIVEMQ_CONNECTOR_OPENWIRE_COMMANDS_BOOLEANEXPRESSION_H_*/ Propchange: incubator/activemq/activemq-cpp/trunk/activemq-cpp/src/main/activemq/connector/openwire/commands/BooleanExpression.h ------------------------------------------------------------------------------ svn:eol-style = native