You are viewing a plain text version of this content. The canonical link for it is here.
Posted to fx-dev@ws.apache.org by ch...@apache.org on 2005/09/30 06:19:48 UTC

svn commit: r292623 - in /webservices/sandesha/trunk/src/org/apache/sandesha2: ./ handlers/ msgprocessors/ msgreceivers/ storage/beanmanagers/ wsrm/

Author: chamikara
Date: Thu Sep 29 21:18:32 2005
New Revision: 292623

URL: http://svn.apache.org/viewcvs?rev=292623&view=rev
Log:
Refactored the Constants class into sub interfaces.

Modified:
    webservices/sandesha/trunk/src/org/apache/sandesha2/Constants.java
    webservices/sandesha/trunk/src/org/apache/sandesha2/MsgInitializer.java
    webservices/sandesha/trunk/src/org/apache/sandesha2/RMMsgContext.java
    webservices/sandesha/trunk/src/org/apache/sandesha2/RMMsgCreator.java
    webservices/sandesha/trunk/src/org/apache/sandesha2/SOAPAbstractFactory.java
    webservices/sandesha/trunk/src/org/apache/sandesha2/SequenceMenager.java
    webservices/sandesha/trunk/src/org/apache/sandesha2/handlers/ServerOutHandler.java
    webservices/sandesha/trunk/src/org/apache/sandesha2/msgprocessors/ApplicationMsgProcessor.java
    webservices/sandesha/trunk/src/org/apache/sandesha2/msgprocessors/CreateSeqMsgProcessor.java
    webservices/sandesha/trunk/src/org/apache/sandesha2/msgprocessors/MsgProcessorFactory.java
    webservices/sandesha/trunk/src/org/apache/sandesha2/msgreceivers/RMMessageReceiver.java
    webservices/sandesha/trunk/src/org/apache/sandesha2/storage/beanmanagers/CreateSeqBeanMgr.java
    webservices/sandesha/trunk/src/org/apache/sandesha2/storage/beanmanagers/NextMsgBeanMgr.java
    webservices/sandesha/trunk/src/org/apache/sandesha2/storage/beanmanagers/RetransmitterBeanMgr.java
    webservices/sandesha/trunk/src/org/apache/sandesha2/storage/beanmanagers/SequencePropertyBeanMgr.java
    webservices/sandesha/trunk/src/org/apache/sandesha2/storage/beanmanagers/StorageMapBeanMgr.java
    webservices/sandesha/trunk/src/org/apache/sandesha2/wsrm/Accept.java
    webservices/sandesha/trunk/src/org/apache/sandesha2/wsrm/AckRequested.java
    webservices/sandesha/trunk/src/org/apache/sandesha2/wsrm/AcknowledgementRange.java
    webservices/sandesha/trunk/src/org/apache/sandesha2/wsrm/AcksTo.java
    webservices/sandesha/trunk/src/org/apache/sandesha2/wsrm/Address.java
    webservices/sandesha/trunk/src/org/apache/sandesha2/wsrm/CreateSequence.java
    webservices/sandesha/trunk/src/org/apache/sandesha2/wsrm/CreateSequenceResponse.java
    webservices/sandesha/trunk/src/org/apache/sandesha2/wsrm/Expires.java
    webservices/sandesha/trunk/src/org/apache/sandesha2/wsrm/FaultCode.java
    webservices/sandesha/trunk/src/org/apache/sandesha2/wsrm/Identifier.java
    webservices/sandesha/trunk/src/org/apache/sandesha2/wsrm/LastMessage.java
    webservices/sandesha/trunk/src/org/apache/sandesha2/wsrm/MessageNumber.java
    webservices/sandesha/trunk/src/org/apache/sandesha2/wsrm/Nack.java
    webservices/sandesha/trunk/src/org/apache/sandesha2/wsrm/Sequence.java
    webservices/sandesha/trunk/src/org/apache/sandesha2/wsrm/SequenceAcknowledgement.java
    webservices/sandesha/trunk/src/org/apache/sandesha2/wsrm/SequenceFault.java
    webservices/sandesha/trunk/src/org/apache/sandesha2/wsrm/SequenceOffer.java
    webservices/sandesha/trunk/src/org/apache/sandesha2/wsrm/TerminateSequence.java

Modified: webservices/sandesha/trunk/src/org/apache/sandesha2/Constants.java
URL: http://svn.apache.org/viewcvs/webservices/sandesha/trunk/src/org/apache/sandesha2/Constants.java?rev=292623&r1=292622&r2=292623&view=diff
==============================================================================
--- webservices/sandesha/trunk/src/org/apache/sandesha2/Constants.java (original)
+++ webservices/sandesha/trunk/src/org/apache/sandesha2/Constants.java Thu Sep 29 21:18:32 2005
@@ -20,24 +20,22 @@
 /**
  * @author Chamikara
  * @author Sanka
- * @author Jaliya 
+ * @author Jaliya
  */
 
-
 public interface Constants {
 
 	public interface WSRM {
 		String NS_PREFIX_RM = "wsrm";
 
 		String NS_URI_RM = "http://schemas.xmlsoap.org/ws/2005/02/rm";
-		
 
 		String ACTION_SEQ_ACK = "http://schemas.xmlsoap.org/ws/2005/02/rm/SequenceAcknowledgement";
-		
+
 		String ACTION_CREATE_SEQ = "http://schemas.xmlsoap.org/ws/2005/02/rm/CreateSequence";
-		
+
 		String NS_URI_CREATE_SEQ_RESPONSE = "http://schemas.xmlsoap.org/ws/2005/02/rm/CreateSequenceResponse";
-		
+
 		String MSG_NUMBER = "MessageNumber";
 
 		String LAST_MSG = "LastMessage";
@@ -53,7 +51,7 @@
 		String SEQUENCE_FAULT = "SequenceFault";
 
 		String ACKS_TO = "AcksTo";
-		
+
 		String EXPIRES = "Expires";
 
 		String CREATE_SEQUENCE = "CreateSequence";
@@ -79,128 +77,117 @@
 
 	public interface WSA {
 		String NS_URI_ANONYMOUS = "http://schemas.xmlsoap.org/ws/2004/08/addressing/role/anonymous";
-		
+
 		String NS_URI_ADDRESSING = "http://schemas.xmlsoap.org/ws/2004/08/addressing";
-		
+
 		String NS_PREFIX_ADDRESSING = "wsa";
-		
+
 		String ADDRESS = "Address";
 	}
 
 	public interface WSP {
 		long RETRANSMISSION_INTERVAL = 20000;
 	}
-	String RM_HEADERS = "rmHeaders";
 
-	String SEQUENCE = "sequence";
+	public interface MessageTypes {
+		int UNKNOWN = 0;
+
+		int CREATE_SEQ = 1;
+
+		int CREATE_SEQ_RESPONSE = 2;
+
+		int APPLICATION = 3;
+
+		int ACK = 4;
+
+		int TERMINATE_SEQ = 5;
+
+		int MAX_MESSAGE_TYPE = 5;
+	}
+
+	public interface MessageParts {
+		int UNKNOWN = 0;
 
-	String MESSAGE_NUMBER = "messageNumber";
+		int SEQUENCE = 6;
 
-	String MESSAGE_TYPE = "messageType";
+		int SEQ_ACKNOWLEDGEMENT = 7;
 
-	String CREATE_SEQ_REQ = "createSequenceReq";
+		int ADDR_HEADERS = 8;
 
-	String CREATE_SEQ_RES = "createSequenceRes";
+		int CREATE_SEQ = 9;
 
-	String ACKNOWLEDGEMENT = "acknowledgement";
+		int CREATE_SEQ_RESPONSE = 10;
 
-	String IN_MESSAGE = "inMessage";
+		int TERMINATE_SEQ = 11;
 
-	String OUT_MESSAGE = "outMessage";
+		int ACK_REQUEST = 12;
 
-	String FAULT_MESSAGE = "faultMessage";
+		int MAX_MSG_PART_ID = 13;
+	}
+
+	public interface SequenceProperties {
+		String RECEIVED_MESSAGES = "SeqMsgListProperty";
+
+		String TO_EPR = "ToEPR";
+
+		String ACKS_TO_EPR = "acksToEPR";
 
-	int MESSAGE_TYPE_UNKNOWN = 0;
+		String OUT_SEQUENCE_ID = "OutSequenceId";
 
-	int MESSAGE_TYPE_CREATE_SEQ = 1;
+		String REPLY_TO_EPR = "ReplyToEPR";
+	}
+
+	public interface SOAPVersion {
+		int v1_1 = 1;
 
-	int MESSAGE_TYPE_CREATE_SEQ_RESPONSE = 2;
+		int v1_2 = 2;
+
+		int DEFAULT = v1_1;
+	}
 
-	int MESSAGE_TYPE_APPLICATION = 3;
+	public interface DeliveryAssurance {
+		String IN_ORDER = "InOrder";
 
-	int MESSAGE_TYPE_ACK = 4;
+		String NOT_IN_ORDER = "NotInOrder";
 
-	int MESSAGE_TYPE_TERMINATE_SEQ = 5;
+		String DEFAULT_DELIVERY_ASSURANCE = NOT_IN_ORDER;
 
-	int MAX_MSG_TYPE = 5;
+		//invocation types
+		String EXACTLY_ONCE = "ExactlyOnce";
 
-	int MESSAGE_PART_UNKNOWN = 0;
+		String MORE_THAN_ONCE = "MoreThanOnce";
 
-	int MESSAGE_PART_SEQUENCE = 1;
+		String DEFAULT_INVOCATION_TYPE = EXACTLY_ONCE;
+	}
 
-	int MESSAGE_PART_SEQ_ACKNOWLEDGEMENT = 2;
+	public interface BeanMAPs {
+		String CREATE_SEQUECE = "CreateSequenceBeanMap";
 
-	int MESSAGE_PART_ADDR_HEADERS = 3;
+		String RETRANSMITTER = "RetransmitterBeanMap";
 
-	int MESSAGE_PART_CREATE_SEQ = 4;
+		String SEQUENCE_PROPERTY = "SequencePropertyBeanMap";
 
-	int MESSAGE_PART_CREATE_SEQ_RESPONSE = 5;
+		String STORAGE_MAP = "StorageMapBeanMap";
 
-	int MESSAGE_PART_TERMINATE_SEQ = 6;
-	
-	int MESSAGE_PART_ACK_REQUEST = 7;
+		String NEXT_MESSAGE = "NextMsgBeanMap";
+	}
 
-	int MAX_MSG_PART_ID = 6;
-	
+	//TODO remove following three
 	int STORAGE_TYPE_IN_MEMORY = 1;
-	
+
 	int STORAGE_TYPE_PERSISTANCE = 2;
-	
+
 	int DEFAULT_STORAGE_TYPE = STORAGE_TYPE_IN_MEMORY;
-	
+
 	String IN_HANDLER_NAME = "SandeshaInHandler";
-	
+
 	String OUT_HANDLER_NAME = "SandeshaOutHandler";
-	
-	
-	//Sequence properties
-	
-	String SEQ_PROPERTY_RECEIVED_MESSAGES = "SeqMsgListProperty";
-	
-	String SEQ_PROPERTY_TO_EPR = "ToEPR";
-	
-	String SEQ_PROPERTY_ACKS_TO_EPR = "acksToEPR";
-	
-	String SEQ_PROPERTY_OUT_SEQUENCE_ID = "OutSequenceId";
-	
-	String SEQ_PROPERTY_REPLY_TO_EPR = "ReplyToEPR";
-	
-	//SOAP versions
-	int SOAP_1_1 = 1;
-	
-	int SOAP_1_2 = 2;
-	
-	int DEFAULT_SOAP_VERSION = SOAP_1_1;
 
-	
 	//message context properties
 	String APPLICATION_PROCESSING_DONE = "APP_PROCESSING_DONE";
-	
-	//delivery assurance.
-	
-	String IN_ORDER = "InOrder";
-	
-	String NOT_IN_ORDER = "NotInOrder";
-	
-	String DEFAULT_DELIVERY_ASSURANCE = NOT_IN_ORDER;
-	
-	//invocation type
-	
-	String EXACTLY_ONCE = "ExactlyOnce";
-	
-	String MORE_THAN_ONCE = "MoreThanOnce";
-	
-	String DEFAULT_INVOCATION_TYPE = EXACTLY_ONCE;
-	
-	
-	String CREATE_SEQUECE_BEAN_MAP = "CreateSequenceBeanMap";
-	
-	String RETRANSMITTER_BEAN_MAP = "RetransmitterBeanMap";
-	
-	String SEQUENCE_PROPERTY_BEAN_MAP = "SequencePropertyBeanMap";
-	
-	String STORAGE_MAP_BEAN_MAP = "StorageMapBeanMap";
-	
-	String NEXT_MESSAGE_BEAN_MAP = "NextMsgBeanMap";
+
+	int INVOKER_SLEEP_TIME = 1000;
+
+	int SENDER_SLEEP_TIME = 1000;
 
 }

Modified: webservices/sandesha/trunk/src/org/apache/sandesha2/MsgInitializer.java
URL: http://svn.apache.org/viewcvs/webservices/sandesha/trunk/src/org/apache/sandesha2/MsgInitializer.java?rev=292623&r1=292622&r2=292623&view=diff
==============================================================================
--- webservices/sandesha/trunk/src/org/apache/sandesha2/MsgInitializer.java (original)
+++ webservices/sandesha/trunk/src/org/apache/sandesha2/MsgInitializer.java Thu Sep 29 21:18:32 2005
@@ -49,33 +49,31 @@
 		elements.fromSOAPEnvelope(msgCtx.getEnvelope());
 
 		if (elements.getCreateSequence() != null)
-			rmMsgContext.setMessagePart(Constants.MESSAGE_PART_CREATE_SEQ,
+			rmMsgContext.setMessagePart(Constants.MessageParts.CREATE_SEQ,
 					elements.getCreateSequence());
 
 		if (elements.getCreateSequenceResponse() != null)
 			rmMsgContext.setMessagePart(
-					Constants.MESSAGE_PART_CREATE_SEQ_RESPONSE, elements
+					Constants.MessageParts.CREATE_SEQ_RESPONSE, elements
 							.getCreateSequenceResponse());
 
 		if (elements.getSequence() != null)
-			rmMsgContext.setMessagePart(Constants.MESSAGE_PART_SEQUENCE,
+			rmMsgContext.setMessagePart(Constants.MessageParts.SEQUENCE,
 					elements.getSequence());
 
 		if (elements.getSequenceAcknowledgement() != null)
 			rmMsgContext.setMessagePart(
-					Constants.MESSAGE_PART_SEQ_ACKNOWLEDGEMENT, elements
+					Constants.MessageParts.SEQ_ACKNOWLEDGEMENT, elements
 							.getSequenceAcknowledgement());
 
 		if (elements.getTerminateSequence() != null)
-			rmMsgContext.setMessagePart(Constants.MESSAGE_PART_TERMINATE_SEQ,
+			rmMsgContext.setMessagePart(Constants.MessageParts.TERMINATE_SEQ,
 					elements.getTerminateSequence());
 
 		if (elements.getAckRequested() != null)
-			rmMsgContext.setMessagePart(Constants.MESSAGE_PART_ACK_REQUEST,
+			rmMsgContext.setMessagePart(Constants.MessageParts.ACK_REQUEST,
 					elements.getAckRequested());
-		
-		
-
+	
 	}
 
 	private static boolean validateMessage(RMMsgContext rmMsgCtx)
@@ -84,19 +82,19 @@
 		//TODO: performa validation
 
 		//Setting message type.
-		if (rmMsgCtx.getMessagePart(Constants.MESSAGE_PART_CREATE_SEQ) != null)
-			rmMsgCtx.setMessageType(Constants.MESSAGE_TYPE_CREATE_SEQ);
+		if (rmMsgCtx.getMessagePart(Constants.MessageParts.CREATE_SEQ) != null)
+			rmMsgCtx.setMessageType(Constants.MessageTypes.CREATE_SEQ);
 		else if (rmMsgCtx
-				.getMessagePart(Constants.MESSAGE_PART_CREATE_SEQ_RESPONSE) != null)
-			rmMsgCtx.setMessageType(Constants.MESSAGE_TYPE_CREATE_SEQ_RESPONSE);
-		else if (rmMsgCtx.getMessagePart(Constants.MESSAGE_PART_TERMINATE_SEQ) != null)
-			rmMsgCtx.setMessageType(Constants.MESSAGE_TYPE_TERMINATE_SEQ);
-		else if (rmMsgCtx.getMessagePart(Constants.MESSAGE_PART_SEQUENCE) != null)
-			rmMsgCtx.setMessageType(Constants.MESSAGE_TYPE_APPLICATION);
-		else if (rmMsgCtx.getMessagePart(Constants.MESSAGE_PART_SEQ_ACKNOWLEDGEMENT)!=null)
-			rmMsgCtx.setMessageType(Constants.MESSAGE_TYPE_ACK);
+				.getMessagePart(Constants.MessageParts.CREATE_SEQ_RESPONSE) != null)
+			rmMsgCtx.setMessageType(Constants.MessageTypes.CREATE_SEQ_RESPONSE);
+		else if (rmMsgCtx.getMessagePart(Constants.MessageParts.TERMINATE_SEQ) != null)
+			rmMsgCtx.setMessageType(Constants.MessageTypes.TERMINATE_SEQ);
+		else if (rmMsgCtx.getMessagePart(Constants.MessageParts.SEQUENCE) != null)
+			rmMsgCtx.setMessageType(Constants.MessageTypes.APPLICATION);
+		else if (rmMsgCtx.getMessagePart(Constants.MessageParts.SEQ_ACKNOWLEDGEMENT)!=null)
+			rmMsgCtx.setMessageType(Constants.MessageTypes.ACK);
 		else
-			rmMsgCtx.setMessageType(Constants.MESSAGE_TYPE_UNKNOWN);
+			rmMsgCtx.setMessageType(Constants.MessageTypes.UNKNOWN);
 
 		return true;
 	}

Modified: webservices/sandesha/trunk/src/org/apache/sandesha2/RMMsgContext.java
URL: http://svn.apache.org/viewcvs/webservices/sandesha/trunk/src/org/apache/sandesha2/RMMsgContext.java?rev=292623&r1=292622&r2=292623&view=diff
==============================================================================
--- webservices/sandesha/trunk/src/org/apache/sandesha2/RMMsgContext.java (original)
+++ webservices/sandesha/trunk/src/org/apache/sandesha2/RMMsgContext.java Thu Sep 29 21:18:32 2005
@@ -54,7 +54,7 @@
 
 	public RMMsgContext() {
 		rmMessageParts = new HashMap();
-		messageType = Constants.MESSAGE_TYPE_UNKNOWN;
+		messageType = Constants.MessageTypes.UNKNOWN;
 	}
 	
 	public void setMessageContext (MessageContext msgCtx) {
@@ -71,7 +71,7 @@
 	public void addSOAPEnvelope() throws AxisFault {
 		if (msgContext.getEnvelope() == null) {
 			msgContext.setEnvelope(SOAPAbstractFactory.getSOAPFactory(
-					Constants.DEFAULT_SOAP_VERSION).getDefaultEnvelope());
+					Constants.SOAPVersion.DEFAULT).getDefaultEnvelope());
 		}
 
 		SOAPEnvelope envelope = msgContext.getEnvelope();
@@ -88,12 +88,12 @@
 	}
 
 	public void setMessageType(int msgType) {
-		if (msgType >= 0 && msgType <= Constants.MAX_MSG_TYPE)
+		if (msgType >= 0 && msgType <= Constants.MessageTypes.MAX_MESSAGE_TYPE)
 			this.messageType = msgType;
 	}
 
 	public void setMessagePart(int partId, IOMRMPart part) {
-		if (partId >= 0 && partId <= Constants.MAX_MSG_PART_ID)
+		if (partId >= 0 && partId <= Constants.MessageParts.MAX_MSG_PART_ID)
 			rmMessageParts.put(new Integer(partId), part);
 	}
 

Modified: webservices/sandesha/trunk/src/org/apache/sandesha2/RMMsgCreator.java
URL: http://svn.apache.org/viewcvs/webservices/sandesha/trunk/src/org/apache/sandesha2/RMMsgCreator.java?rev=292623&r1=292622&r2=292623&view=diff
==============================================================================
--- webservices/sandesha/trunk/src/org/apache/sandesha2/RMMsgCreator.java (original)
+++ webservices/sandesha/trunk/src/org/apache/sandesha2/RMMsgCreator.java Thu Sep 29 21:18:32 2005
@@ -100,7 +100,7 @@
 
 			//Setting a new SOAP Envelop.
 			SOAPEnvelope envelope = SOAPAbstractFactory.getSOAPFactory(
-					Constants.DEFAULT_SOAP_VERSION).getDefaultEnvelope();
+					Constants.SOAPVersion.DEFAULT).getDefaultEnvelope();
 
 			createSeqmsgContext.setEnvelope(envelope);
 			createSeqOpContext.addMessageContext(createSeqmsgContext);
@@ -120,7 +120,7 @@
 		EndpointReference acksToEPR = applicationRMMsg.getReplyTo();
 
 		createSequencePart.setAcksTo(new AcksTo(new Address(acksToEPR)));
-		createSeqRMMsg.setMessagePart(Constants.MESSAGE_PART_CREATE_SEQ,
+		createSeqRMMsg.setMessagePart(Constants.MessageParts.CREATE_SEQ,
 				createSequencePart);
 
 		try {
@@ -164,7 +164,7 @@
 			throws AxisFault {
 
 		IOMRMElement messagePart = createSeqMessage
-				.getMessagePart(Constants.MESSAGE_PART_CREATE_SEQ);
+				.getMessagePart(Constants.MessageParts.CREATE_SEQ);
 		CreateSequence cs = (CreateSequence) messagePart;
 
 		CreateSequenceResponse response = new CreateSequenceResponse();
@@ -185,7 +185,7 @@
 		response.setAccept(accept);
 
 		SOAPEnvelope envelope = SOAPAbstractFactory.getSOAPFactory(
-				Constants.DEFAULT_SOAP_VERSION).getDefaultEnvelope();
+				Constants.SOAPVersion.DEFAULT).getDefaultEnvelope();
 		response.toOMElement(envelope.getBody());
 		outMessage.setWSAAction(Constants.WSRM.NS_URI_CREATE_SEQ_RESPONSE);
 
@@ -210,7 +210,7 @@
 		SOAPEnvelope envelope = applicationMsg.getSOAPEnvelope();
 		if (envelope == null) {
 			SOAPEnvelope newEnvelope = SOAPAbstractFactory.getSOAPFactory(
-					Constants.DEFAULT_SOAP_VERSION).getDefaultEnvelope();
+					Constants.SOAPVersion.DEFAULT).getDefaultEnvelope();
 			applicationMsg.setSOAPEnvelop(newEnvelope);
 		}
 		envelope = applicationMsg.getSOAPEnvelope();
@@ -226,7 +226,7 @@
 				.getInstance(ctx).getSequencePropretyBeanMgr();
 
 		SequencePropertyBean seqBean = seqPropMgr.retrieve(sequenceId,
-				Constants.SEQ_PROPERTY_RECEIVED_MESSAGES);
+				Constants.SequenceProperties.RECEIVED_MESSAGES);
 		String msgNoList = (String) seqBean.getValue();
 		System.out.println("Message No List:" + msgNoList);
 
@@ -269,7 +269,7 @@
 			ackOpCtx.addMessageContext(ackMsgCtx);
 
 			Sequence reqSequence = (Sequence) applicationRMMsgCtx
-					.getMessagePart(Constants.MESSAGE_PART_SEQUENCE);
+					.getMessagePart(Constants.MessageParts.SEQUENCE);
 			if (reqSequence == null)
 				throw new SandeshaException(
 						"Sequence part of application message is null");

Modified: webservices/sandesha/trunk/src/org/apache/sandesha2/SOAPAbstractFactory.java
URL: http://svn.apache.org/viewcvs/webservices/sandesha/trunk/src/org/apache/sandesha2/SOAPAbstractFactory.java?rev=292623&r1=292622&r2=292623&view=diff
==============================================================================
--- webservices/sandesha/trunk/src/org/apache/sandesha2/SOAPAbstractFactory.java (original)
+++ webservices/sandesha/trunk/src/org/apache/sandesha2/SOAPAbstractFactory.java Thu Sep 29 21:18:32 2005
@@ -30,9 +30,9 @@
 public class SOAPAbstractFactory {
 
 	public static SOAPFactory getSOAPFactory (int SOAPVersion) {
-		if (SOAPVersion==Constants.SOAP_1_1)
+		if (SOAPVersion==Constants.SOAPVersion.v1_1)
 			return OMAbstractFactory.getSOAP11Factory();
-		else if(SOAPVersion==Constants.SOAP_1_2)
+		else if(SOAPVersion==Constants.SOAPVersion.v1_2)
 			return OMAbstractFactory.getSOAP12Factory();
 		else
 			return null;

Modified: webservices/sandesha/trunk/src/org/apache/sandesha2/SequenceMenager.java
URL: http://svn.apache.org/viewcvs/webservices/sandesha/trunk/src/org/apache/sandesha2/SequenceMenager.java?rev=292623&r1=292622&r2=292623&view=diff
==============================================================================
--- webservices/sandesha/trunk/src/org/apache/sandesha2/SequenceMenager.java (original)
+++ webservices/sandesha/trunk/src/org/apache/sandesha2/SequenceMenager.java Thu Sep 29 21:18:32 2005
@@ -49,7 +49,7 @@
 			throw new AxisFault("ReplyTo is null");
 
 		CreateSequence createSequence = (CreateSequence) createSequenceMsg
-				.getMessagePart(Constants.MESSAGE_PART_CREATE_SEQ);
+				.getMessagePart(Constants.MessageParts.CREATE_SEQ);
 		if (createSequence == null)
 			throw new AxisFault("Create Sequence Part is null");
 
@@ -63,13 +63,13 @@
 				.getInstance(context).getSequencePropretyBeanMgr();
 
 		SequencePropertyBean receivedMsgBean = new SequencePropertyBean(
-				sequenceId, Constants.SEQ_PROPERTY_RECEIVED_MESSAGES, "");
+				sequenceId, Constants.SequenceProperties.RECEIVED_MESSAGES, "");
 		SequencePropertyBean toBean = new SequencePropertyBean (sequenceId,
-				Constants.SEQ_PROPERTY_TO_EPR,to);
+				Constants.SequenceProperties.TO_EPR,to);
 		SequencePropertyBean replyToBean = new SequencePropertyBean(sequenceId,
-				Constants.SEQ_PROPERTY_REPLY_TO_EPR, replyTo);
+				Constants.SequenceProperties.REPLY_TO_EPR, replyTo);
 		SequencePropertyBean acksToBean = new SequencePropertyBean(sequenceId,
-				Constants.SEQ_PROPERTY_ACKS_TO_EPR, acksTo);
+				Constants.SequenceProperties.ACKS_TO_EPR, acksTo);
 
 		seqPropMgr.insert(receivedMsgBean);
 		seqPropMgr.insert(toBean);

Modified: webservices/sandesha/trunk/src/org/apache/sandesha2/handlers/ServerOutHandler.java
URL: http://svn.apache.org/viewcvs/webservices/sandesha/trunk/src/org/apache/sandesha2/handlers/ServerOutHandler.java?rev=292623&r1=292622&r2=292623&view=diff
==============================================================================
--- webservices/sandesha/trunk/src/org/apache/sandesha2/handlers/ServerOutHandler.java (original)
+++ webservices/sandesha/trunk/src/org/apache/sandesha2/handlers/ServerOutHandler.java Thu Sep 29 21:18:32 2005
@@ -83,7 +83,7 @@
 		RMMsgContext requestRMMsgCtx;
 		try {
 			requestRMMsgCtx = MsgInitializer.initializeMessage(reqMsgCtx);
-			if (rmMsgCtx.getMessageType() == Constants.MESSAGE_TYPE_UNKNOWN) {
+			if (rmMsgCtx.getMessageType() == Constants.MessageTypes.UNKNOWN) {
 
 				System.out.println("GOT Possible Response Message");
 				AbstractContext context = rmMsgCtx.getContext();
@@ -91,7 +91,7 @@
 					throw new SandeshaException("Context is null");
 
 				Sequence sequence = (Sequence) requestRMMsgCtx
-						.getMessagePart(Constants.MESSAGE_PART_SEQUENCE);
+						.getMessagePart(Constants.MessageParts.SEQUENCE);
 				if (sequence == null)
 					throw new SandeshaException("Sequence part is null");
 
@@ -102,7 +102,7 @@
 				SequencePropertyBeanMgr seqPropMgr = AbstractBeanMgrFactory
 						.getInstance(context).getSequencePropretyBeanMgr();
 				SequencePropertyBean acksToBean = seqPropMgr.retrieve(
-						incomingSeqId, Constants.SEQ_PROPERTY_ACKS_TO_EPR);
+						incomingSeqId, Constants.SequenceProperties.ACKS_TO_EPR);
 				if (acksToBean == null
 						|| acksToBean.getValue() == null
 						|| !(acksToBean.getValue() instanceof EndpointReference))
@@ -117,7 +117,7 @@
 				SOAPEnvelope env = rmMsgCtx.getSOAPEnvelope();
 				if (env == null) {
 					SOAPEnvelope envelope = SOAPAbstractFactory.getSOAPFactory(
-							Constants.DEFAULT_SOAP_VERSION)
+							Constants.SOAPVersion.DEFAULT)
 							.getDefaultEnvelope();
 					rmMsgCtx.setSOAPEnvelop(envelope);
 				}
@@ -134,7 +134,7 @@
 					if (Constants.WSA.NS_URI_ANONYMOUS.equals(acksToEPR
 							.getAddress())) {
 						Sequence reqSequence = (Sequence) requestRMMsgCtx
-								.getMessagePart(Constants.MESSAGE_PART_SEQUENCE);
+								.getMessagePart(Constants.MessageParts.SEQUENCE);
 						if (reqSequence == null)
 							throw new SandeshaException(
 									"Sequence part of application message is null");
@@ -198,7 +198,7 @@
 			throw new SandeshaException("Message or reques message is null");
 
 		Sequence sequence = (Sequence) reqRMMsg
-				.getMessagePart(Constants.MESSAGE_PART_SEQUENCE);
+				.getMessagePart(Constants.MessageParts.SEQUENCE);
 		if (sequence == null)
 			throw new SandeshaException("Sequence part is null");
 
@@ -214,11 +214,11 @@
 				context).getSequencePropretyBeanMgr();
 
 		SequencePropertyBean toBean = mgr.retrieve(incomingSeqId,
-				Constants.SEQ_PROPERTY_TO_EPR);
+				Constants.SequenceProperties.TO_EPR);
 		SequencePropertyBean replyToBean = mgr.retrieve(incomingSeqId,
-				Constants.SEQ_PROPERTY_REPLY_TO_EPR);
+				Constants.SequenceProperties.REPLY_TO_EPR);
 		SequencePropertyBean outSequenceBean = mgr.retrieve(incomingSeqId,
-				Constants.SEQ_PROPERTY_OUT_SEQUENCE_ID);
+				Constants.SequenceProperties.OUT_SEQUENCE_ID);
 
 		if (toBean == null)
 			throw new SandeshaException("To is null");

Modified: webservices/sandesha/trunk/src/org/apache/sandesha2/msgprocessors/ApplicationMsgProcessor.java
URL: http://svn.apache.org/viewcvs/webservices/sandesha/trunk/src/org/apache/sandesha2/msgprocessors/ApplicationMsgProcessor.java?rev=292623&r1=292622&r2=292623&view=diff
==============================================================================
--- webservices/sandesha/trunk/src/org/apache/sandesha2/msgprocessors/ApplicationMsgProcessor.java (original)
+++ webservices/sandesha/trunk/src/org/apache/sandesha2/msgprocessors/ApplicationMsgProcessor.java Thu Sep 29 21:18:32 2005
@@ -74,7 +74,7 @@
 
 		//setting acked msg no range
 		Sequence sequence = (Sequence) rmMsgCtx
-				.getMessagePart(Constants.MESSAGE_PART_SEQUENCE);
+				.getMessagePart(Constants.MessageParts.SEQUENCE);
 		String sequenceId = sequence.getIdentifier().getIdentifier();
 		ConfigurationContext configCtx = rmMsgCtx.getMessageContext()
 				.getSystemContext();
@@ -84,7 +84,7 @@
 		SequencePropertyBeanMgr seqPropMgr = AbstractBeanMgrFactory
 				.getInstance(configCtx).getSequencePropretyBeanMgr();
 		SequencePropertyBean msgsBean = seqPropMgr.retrieve(sequenceId,
-				Constants.SEQ_PROPERTY_RECEIVED_MESSAGES);
+				Constants.SequenceProperties.RECEIVED_MESSAGES);
 
 		long msgNo = sequence.getMessageNumber().getMessageNumber();
 		if (msgNo == 0)
@@ -93,7 +93,7 @@
 		String messagesStr = (String) msgsBean.getValue();
 
 		if (msgNoPresentInList(messagesStr, msgNo)
-				&& (Constants.DEFAULT_INVOCATION_TYPE == Constants.EXACTLY_ONCE)) {
+				&& (Constants.DeliveryAssurance.DEFAULT_INVOCATION_TYPE == Constants.DeliveryAssurance.EXACTLY_ONCE)) {
 			//this is a duplicate message and the invocation type is
 			// EXACTLY_ONCE.
 			throw new SandeshaException(
@@ -111,7 +111,7 @@
 		//Setting the ack depending on AcksTo.
 		//TODO: Stop sending askc for every message.
 		SequencePropertyBean acksToBean = seqPropMgr.retrieve(sequenceId,
-				Constants.SEQ_PROPERTY_ACKS_TO_EPR);
+				Constants.SequenceProperties.ACKS_TO_EPR);
 		String acksToStr = null;
 		try {
 			EndpointReference acksTo = (EndpointReference) acksToBean
@@ -152,7 +152,7 @@
 
 			//Set new envelope
 			SOAPEnvelope envelope = SOAPAbstractFactory.getSOAPFactory(
-					Constants.DEFAULT_SOAP_VERSION).getDefaultEnvelope();
+					Constants.SOAPVersion.DEFAULT).getDefaultEnvelope();
 			try {
 				ackMsgCtx.setEnvelope(envelope);
 			} catch (AxisFault e3) {
@@ -216,7 +216,7 @@
 			// should have been
 			//		detected previously)
 
-			if (Constants.DEFAULT_DELIVERY_ASSURANCE == Constants.IN_ORDER) {
+			if (Constants.DeliveryAssurance.DEFAULT_DELIVERY_ASSURANCE == Constants.DeliveryAssurance.IN_ORDER) {
 				//store and let invoker handle for IN_ORDER invocation
 				//rmMsgCtx.getMessageContext().setPausedTrue(new QName
 				// (Constants.IN_HANDLER_NAME));
@@ -243,7 +243,10 @@
 			}
 		}
 
-		int i = 1;
+
+		//wait till InOrderInvoker allows me.
+		//TODO analyze and optimize performance
+		
 	}
 
 	//TODO convert following from INT to LONG

Modified: webservices/sandesha/trunk/src/org/apache/sandesha2/msgprocessors/CreateSeqMsgProcessor.java
URL: http://svn.apache.org/viewcvs/webservices/sandesha/trunk/src/org/apache/sandesha2/msgprocessors/CreateSeqMsgProcessor.java?rev=292623&r1=292622&r2=292623&view=diff
==============================================================================
--- webservices/sandesha/trunk/src/org/apache/sandesha2/msgprocessors/CreateSeqMsgProcessor.java (original)
+++ webservices/sandesha/trunk/src/org/apache/sandesha2/msgprocessors/CreateSeqMsgProcessor.java Thu Sep 29 21:18:32 2005
@@ -30,7 +30,7 @@
 
 	public void processMessage(RMMsgContext rmMsgCtx) throws SandeshaException {
 		//TODO: Add create sequence message processing logic
-		CreateSequence createSeq = (CreateSequence) rmMsgCtx.getMessagePart(Constants.MESSAGE_PART_CREATE_SEQ);
+		CreateSequence createSeq = (CreateSequence) rmMsgCtx.getMessagePart(Constants.MessageParts.CREATE_SEQ);
 
 		//rmMsgCtx.test();
 	

Modified: webservices/sandesha/trunk/src/org/apache/sandesha2/msgprocessors/MsgProcessorFactory.java
URL: http://svn.apache.org/viewcvs/webservices/sandesha/trunk/src/org/apache/sandesha2/msgprocessors/MsgProcessorFactory.java?rev=292623&r1=292622&r2=292623&view=diff
==============================================================================
--- webservices/sandesha/trunk/src/org/apache/sandesha2/msgprocessors/MsgProcessorFactory.java (original)
+++ webservices/sandesha/trunk/src/org/apache/sandesha2/msgprocessors/MsgProcessorFactory.java Thu Sep 29 21:18:32 2005
@@ -28,11 +28,11 @@
 	public static MsgProcessor getMessageProcessor (int msgType) {
 		switch (msgType)
 		{
-			case (Constants.MESSAGE_TYPE_CREATE_SEQ):
+			case (Constants.MessageTypes.CREATE_SEQ):
 				return new CreateSeqMsgProcessor ();
-			case (Constants.MESSAGE_TYPE_TERMINATE_SEQ):
+			case (Constants.MessageTypes.TERMINATE_SEQ):
 				return new TerminateSeqMsgProcessor ();
-			case (Constants.MESSAGE_TYPE_APPLICATION):
+			case (Constants.MessageTypes.APPLICATION):
 				return new ApplicationMsgProcessor ();
 			default:
 				return null;

Modified: webservices/sandesha/trunk/src/org/apache/sandesha2/msgreceivers/RMMessageReceiver.java
URL: http://svn.apache.org/viewcvs/webservices/sandesha/trunk/src/org/apache/sandesha2/msgreceivers/RMMessageReceiver.java?rev=292623&r1=292622&r2=292623&view=diff
==============================================================================
--- webservices/sandesha/trunk/src/org/apache/sandesha2/msgreceivers/RMMessageReceiver.java (original)
+++ webservices/sandesha/trunk/src/org/apache/sandesha2/msgreceivers/RMMessageReceiver.java Thu Sep 29 21:18:32 2005
@@ -78,13 +78,13 @@
 			throw new AxisFault("Cant initialize the message");
 		}
 
-		if (createSeqMsg.getMessageType() != Constants.MESSAGE_TYPE_CREATE_SEQ)
+		if (createSeqMsg.getMessageType() != Constants.MessageTypes.CREATE_SEQ)
 			throw new AxisFault("Wrong message type");
 
 		RMMsgContext createSeqResponse = RMMsgCreator
 				.createCreateSeqResponseMsg(createSeqMsg, outMessage);
 		CreateSequenceResponse createSeqResPart = (CreateSequenceResponse) createSeqResponse
-				.getMessagePart(Constants.MESSAGE_PART_CREATE_SEQ_RESPONSE);
+				.getMessagePart(Constants.MessageParts.CREATE_SEQ_RESPONSE);
 
 		String newSequenceId = createSeqResPart.getIdentifier().getIdentifier();
 		if (newSequenceId == null)
@@ -95,7 +95,7 @@
 		SequenceMenager.setUpNewSequence(newSequenceId, createSeqMsg);
 
 		CreateSequence createSeq = (CreateSequence) createSeqMsg
-				.getMessagePart(Constants.MESSAGE_PART_CREATE_SEQ);
+				.getMessagePart(Constants.MessageParts.CREATE_SEQ);
 		if (createSeq == null)
 			throw new AxisFault(
 					"Create sequence part not present in the create sequence message");
@@ -107,7 +107,7 @@
 					"Acks to not present in the create sequence message");
 
 		SequencePropertyBean seqPropBean = new SequencePropertyBean(
-				newSequenceId, Constants.SEQ_PROPERTY_ACKS_TO_EPR, acksTo);
+				newSequenceId, Constants.SequenceProperties.ACKS_TO_EPR, acksTo);
 		//		SequencePropertyBeanMgr beanMgr = new SequencePropertyBeanMgr
 		// (Constants.DEFAULT_STORAGE_TYPE);
 		//		beanMgr.create(seqPropBean);
@@ -134,13 +134,13 @@
 		AbstractMessageReceiver msgReceiver = null;
 
 		String replyTo = messgeCtx.getFrom().getAddress();
-		if (rmMsgCtx.getMessageType() == Constants.MESSAGE_TYPE_TERMINATE_SEQ)
+		if (rmMsgCtx.getMessageType() == Constants.MessageTypes.TERMINATE_SEQ)
 			msgReceiver = new RMInMsgReceiver();
-		else if (rmMsgCtx.getMessageType() == Constants.MESSAGE_TYPE_CREATE_SEQ
+		else if (rmMsgCtx.getMessageType() == Constants.MessageTypes.CREATE_SEQ
 				&& ((replyTo == null) || replyTo
 						.equals(Constants.WSA.NS_URI_ANONYMOUS)))
 			msgReceiver = new RMInOutSyncMsgReceiver();
-		else if (rmMsgCtx.getMessageType() == Constants.MESSAGE_TYPE_CREATE_SEQ)
+		else if (rmMsgCtx.getMessageType() == Constants.MessageTypes.CREATE_SEQ)
 			msgReceiver = new RMInOutAsyncMsgReceiver();
 
 		if (msgReceiver != null) {
@@ -192,7 +192,7 @@
 				throw new AxisFault("Cant initialize the message");
 			}
 
-			if (rmMsgCtx.getMessageType() == Constants.MESSAGE_TYPE_CREATE_SEQ) {
+			if (rmMsgCtx.getMessageType() == Constants.MessageTypes.CREATE_SEQ) {
 				//TODO handle sync create seq.
 				setCreateSequence(inMessage, outMessage);
 			}
@@ -214,7 +214,7 @@
 				throw new AxisFault("Cant initialize the message");
 			}
 
-			if (rmMsgCtx.getMessageType() == Constants.MESSAGE_TYPE_CREATE_SEQ) {
+			if (rmMsgCtx.getMessageType() == Constants.MessageTypes.CREATE_SEQ) {
 				//TODO handle async create seq.
 				setCreateSequence(inMessage, outMessage);
 				ConfigurationContext configCtx = outMessage.getSystemContext();

Modified: webservices/sandesha/trunk/src/org/apache/sandesha2/storage/beanmanagers/CreateSeqBeanMgr.java
URL: http://svn.apache.org/viewcvs/webservices/sandesha/trunk/src/org/apache/sandesha2/storage/beanmanagers/CreateSeqBeanMgr.java?rev=292623&r1=292622&r2=292623&view=diff
==============================================================================
--- webservices/sandesha/trunk/src/org/apache/sandesha2/storage/beanmanagers/CreateSeqBeanMgr.java (original)
+++ webservices/sandesha/trunk/src/org/apache/sandesha2/storage/beanmanagers/CreateSeqBeanMgr.java Thu Sep 29 21:18:32 2005
@@ -41,12 +41,12 @@
 	 *  
 	 */
 	public CreateSeqBeanMgr(AbstractContext context) {
-		Object obj = context.getProperty(Constants.CREATE_SEQUECE_BEAN_MAP);
+		Object obj = context.getProperty(Constants.BeanMAPs.CREATE_SEQUECE);
 		if (obj != null) {
 			table = (Hashtable) obj;
 		} else {
 			table = new Hashtable();
-			context.setProperty(Constants.CREATE_SEQUECE_BEAN_MAP, table);
+			context.setProperty(Constants.BeanMAPs.CREATE_SEQUECE, table);
 		}
 	}
 

Modified: webservices/sandesha/trunk/src/org/apache/sandesha2/storage/beanmanagers/NextMsgBeanMgr.java
URL: http://svn.apache.org/viewcvs/webservices/sandesha/trunk/src/org/apache/sandesha2/storage/beanmanagers/NextMsgBeanMgr.java?rev=292623&r1=292622&r2=292623&view=diff
==============================================================================
--- webservices/sandesha/trunk/src/org/apache/sandesha2/storage/beanmanagers/NextMsgBeanMgr.java (original)
+++ webservices/sandesha/trunk/src/org/apache/sandesha2/storage/beanmanagers/NextMsgBeanMgr.java Thu Sep 29 21:18:32 2005
@@ -40,13 +40,13 @@
 	 *  
 	 */
 	public NextMsgBeanMgr(AbstractContext context) {
-		Object obj = context.getProperty(Constants.STORAGE_MAP_BEAN_MAP);
+		Object obj = context.getProperty(Constants.BeanMAPs.NEXT_MESSAGE);
 
 		if (obj != null) {
 			table = (Hashtable) obj;
 		} else {
 			table = new Hashtable();
-			context.setProperty(Constants.STORAGE_MAP_BEAN_MAP, table);
+			context.setProperty(Constants.BeanMAPs.NEXT_MESSAGE, table);
 		}
 	}
 

Modified: webservices/sandesha/trunk/src/org/apache/sandesha2/storage/beanmanagers/RetransmitterBeanMgr.java
URL: http://svn.apache.org/viewcvs/webservices/sandesha/trunk/src/org/apache/sandesha2/storage/beanmanagers/RetransmitterBeanMgr.java?rev=292623&r1=292622&r2=292623&view=diff
==============================================================================
--- webservices/sandesha/trunk/src/org/apache/sandesha2/storage/beanmanagers/RetransmitterBeanMgr.java (original)
+++ webservices/sandesha/trunk/src/org/apache/sandesha2/storage/beanmanagers/RetransmitterBeanMgr.java Thu Sep 29 21:18:32 2005
@@ -39,12 +39,12 @@
 	 *  
 	 */
 	public RetransmitterBeanMgr(AbstractContext context) {
-		Object obj = context.getProperty(Constants.RETRANSMITTER_BEAN_MAP);
+		Object obj = context.getProperty(Constants.BeanMAPs.RETRANSMITTER);
 		if (obj != null) {
 			table = (Hashtable) obj;
 		} else {
 			table = new Hashtable();
-			context.setProperty(Constants.RETRANSMITTER_BEAN_MAP, table);
+			context.setProperty(Constants.BeanMAPs.RETRANSMITTER, table);
 		}
 	}
 

Modified: webservices/sandesha/trunk/src/org/apache/sandesha2/storage/beanmanagers/SequencePropertyBeanMgr.java
URL: http://svn.apache.org/viewcvs/webservices/sandesha/trunk/src/org/apache/sandesha2/storage/beanmanagers/SequencePropertyBeanMgr.java?rev=292623&r1=292622&r2=292623&view=diff
==============================================================================
--- webservices/sandesha/trunk/src/org/apache/sandesha2/storage/beanmanagers/SequencePropertyBeanMgr.java (original)
+++ webservices/sandesha/trunk/src/org/apache/sandesha2/storage/beanmanagers/SequencePropertyBeanMgr.java Thu Sep 29 21:18:32 2005
@@ -39,12 +39,12 @@
 	 *  
 	 */
 	public SequencePropertyBeanMgr(AbstractContext context) {
-		Object obj = context.getProperty(Constants.SEQUENCE_PROPERTY_BEAN_MAP);
+		Object obj = context.getProperty(Constants.BeanMAPs.SEQUENCE_PROPERTY);
 		if (obj != null) {
 			table = (Hashtable) obj;
 		} else {
 			table = new Hashtable();
-			context.setProperty(Constants.SEQUENCE_PROPERTY_BEAN_MAP, table);
+			context.setProperty(Constants.BeanMAPs.SEQUENCE_PROPERTY, table);
 		}
 	}
 

Modified: webservices/sandesha/trunk/src/org/apache/sandesha2/storage/beanmanagers/StorageMapBeanMgr.java
URL: http://svn.apache.org/viewcvs/webservices/sandesha/trunk/src/org/apache/sandesha2/storage/beanmanagers/StorageMapBeanMgr.java?rev=292623&r1=292622&r2=292623&view=diff
==============================================================================
--- webservices/sandesha/trunk/src/org/apache/sandesha2/storage/beanmanagers/StorageMapBeanMgr.java (original)
+++ webservices/sandesha/trunk/src/org/apache/sandesha2/storage/beanmanagers/StorageMapBeanMgr.java Thu Sep 29 21:18:32 2005
@@ -40,12 +40,12 @@
 	 *  
 	 */
 	public StorageMapBeanMgr(AbstractContext context) {
-		Object obj = context.getProperty(Constants.STORAGE_MAP_BEAN_MAP);
+		Object obj = context.getProperty(Constants.BeanMAPs.STORAGE_MAP);
 		if (obj != null) {
 			table = (Hashtable) obj;
 		} else {
 			table = new Hashtable();
-			context.setProperty(Constants.STORAGE_MAP_BEAN_MAP, table);
+			context.setProperty(Constants.BeanMAPs.STORAGE_MAP, table);
 		}
 	}
 

Modified: webservices/sandesha/trunk/src/org/apache/sandesha2/wsrm/Accept.java
URL: http://svn.apache.org/viewcvs/webservices/sandesha/trunk/src/org/apache/sandesha2/wsrm/Accept.java?rev=292623&r1=292622&r2=292623&view=diff
==============================================================================
--- webservices/sandesha/trunk/src/org/apache/sandesha2/wsrm/Accept.java (original)
+++ webservices/sandesha/trunk/src/org/apache/sandesha2/wsrm/Accept.java Thu Sep 29 21:18:32 2005
@@ -41,12 +41,12 @@
 	private AcksTo acksTo;
 
 	OMNamespace rmNamespace = SOAPAbstractFactory.getSOAPFactory(
-			Constants.DEFAULT_SOAP_VERSION).createOMNamespace(
+			Constants.SOAPVersion.DEFAULT).createOMNamespace(
 			Constants.WSRM.NS_URI_RM, Constants.WSRM.NS_PREFIX_RM);
 
 	public Accept() {
 		acceptElement = SOAPAbstractFactory.getSOAPFactory(
-				Constants.DEFAULT_SOAP_VERSION).createOMElement(
+				Constants.SOAPVersion.DEFAULT).createOMElement(
 				Constants.WSRM.ACCEPT, rmNamespace);
 	}
 
@@ -66,7 +66,7 @@
 		acksTo.fromOMElement(acceptPart);
 
 		acceptElement = SOAPAbstractFactory.getSOAPFactory(
-				Constants.DEFAULT_SOAP_VERSION).createOMElement(
+				Constants.SOAPVersion.DEFAULT).createOMElement(
 				Constants.WSRM.ACCEPT, rmNamespace);
 
 		return this;
@@ -86,7 +86,7 @@
 		element.addChild(acceptElement);
 
 		acceptElement = SOAPAbstractFactory.getSOAPFactory(
-				Constants.DEFAULT_SOAP_VERSION).createOMElement(
+				Constants.SOAPVersion.DEFAULT).createOMElement(
 				Constants.WSRM.ACCEPT, rmNamespace);
 
 		return element;

Modified: webservices/sandesha/trunk/src/org/apache/sandesha2/wsrm/AckRequested.java
URL: http://svn.apache.org/viewcvs/webservices/sandesha/trunk/src/org/apache/sandesha2/wsrm/AckRequested.java?rev=292623&r1=292622&r2=292623&view=diff
==============================================================================
--- webservices/sandesha/trunk/src/org/apache/sandesha2/wsrm/AckRequested.java (original)
+++ webservices/sandesha/trunk/src/org/apache/sandesha2/wsrm/AckRequested.java Thu Sep 29 21:18:32 2005
@@ -42,12 +42,12 @@
 	private MessageNumber messageNumber;
 
 	OMNamespace rmNamespace = SOAPAbstractFactory.getSOAPFactory(
-			Constants.DEFAULT_SOAP_VERSION).createOMNamespace(
+			Constants.SOAPVersion.DEFAULT).createOMNamespace(
 			Constants.WSRM.NS_URI_RM, Constants.WSRM.NS_PREFIX_RM);
 
 	public AckRequested() {
 		ackRequestedElement = SOAPAbstractFactory.getSOAPFactory(
-				Constants.DEFAULT_SOAP_VERSION).createOMElement(
+				Constants.SOAPVersion.DEFAULT).createOMElement(
 				Constants.WSRM.ACK_REQUESTED, rmNamespace);
 	}
 
@@ -80,7 +80,7 @@
 		}
 
 		ackRequestedElement = SOAPAbstractFactory.getSOAPFactory(
-				Constants.DEFAULT_SOAP_VERSION).createOMElement(
+				Constants.SOAPVersion.DEFAULT).createOMElement(
 				Constants.WSRM.ACK_REQUESTED, rmNamespace);
 
 		return this;
@@ -108,7 +108,7 @@
 		}
 
 		ackRequestedElement = SOAPAbstractFactory.getSOAPFactory(
-				Constants.DEFAULT_SOAP_VERSION).createOMElement(
+				Constants.SOAPVersion.DEFAULT).createOMElement(
 				Constants.WSRM.ACK_REQUESTED, rmNamespace);
 
 		return header;

Modified: webservices/sandesha/trunk/src/org/apache/sandesha2/wsrm/AcknowledgementRange.java
URL: http://svn.apache.org/viewcvs/webservices/sandesha/trunk/src/org/apache/sandesha2/wsrm/AcknowledgementRange.java?rev=292623&r1=292622&r2=292623&view=diff
==============================================================================
--- webservices/sandesha/trunk/src/org/apache/sandesha2/wsrm/AcknowledgementRange.java (original)
+++ webservices/sandesha/trunk/src/org/apache/sandesha2/wsrm/AcknowledgementRange.java Thu Sep 29 21:18:32 2005
@@ -49,12 +49,12 @@
 	private long lowerValue;
 
 	OMNamespace rmNamespace = SOAPAbstractFactory.getSOAPFactory(
-			Constants.DEFAULT_SOAP_VERSION).createOMNamespace(
+			Constants.SOAPVersion.DEFAULT).createOMNamespace(
 			Constants.WSRM.NS_URI_RM, Constants.WSRM.NS_PREFIX_RM);
 
 	public AcknowledgementRange() {
 		acknowledgementRangeElement = SOAPAbstractFactory.getSOAPFactory(
-				Constants.DEFAULT_SOAP_VERSION).createOMElement(
+				Constants.SOAPVersion.DEFAULT).createOMElement(
 				Constants.WSRM.ACK_RANGE, rmNamespace);
 	}
 
@@ -106,7 +106,7 @@
 		}
 
 		acknowledgementRangeElement = SOAPAbstractFactory.getSOAPFactory(
-				Constants.DEFAULT_SOAP_VERSION).createOMElement(
+				Constants.SOAPVersion.DEFAULT).createOMElement(
 				Constants.WSRM.ACK_RANGE, rmNamespace);
 
 		return this;
@@ -124,10 +124,10 @@
 					"Cant set Ack Range part since Upper or Lower is not set to the correct value");
 
 		OMAttribute lowerAttrib = SOAPAbstractFactory.getSOAPFactory(
-				Constants.DEFAULT_SOAP_VERSION).createOMAttribute(
+				Constants.SOAPVersion.DEFAULT).createOMAttribute(
 				Constants.WSRM.LOWER, rmNamespace, Long.toString(lowerValue));
 		OMAttribute upperAttrib = SOAPAbstractFactory.getSOAPFactory(
-				Constants.DEFAULT_SOAP_VERSION).createOMAttribute(
+				Constants.SOAPVersion.DEFAULT).createOMAttribute(
 				Constants.WSRM.UPPER, rmNamespace, Long.toString(upperValue));
 
 		acknowledgementRangeElement.addAttribute(lowerAttrib);
@@ -136,7 +136,7 @@
 		sequenceAckElement.addChild(acknowledgementRangeElement);
 
 		acknowledgementRangeElement = SOAPAbstractFactory.getSOAPFactory(
-				Constants.DEFAULT_SOAP_VERSION).createOMElement(
+				Constants.SOAPVersion.DEFAULT).createOMElement(
 				Constants.WSRM.ACK_RANGE, rmNamespace);
 
 		return sequenceAckElement;

Modified: webservices/sandesha/trunk/src/org/apache/sandesha2/wsrm/AcksTo.java
URL: http://svn.apache.org/viewcvs/webservices/sandesha/trunk/src/org/apache/sandesha2/wsrm/AcksTo.java?rev=292623&r1=292622&r2=292623&view=diff
==============================================================================
--- webservices/sandesha/trunk/src/org/apache/sandesha2/wsrm/AcksTo.java (original)
+++ webservices/sandesha/trunk/src/org/apache/sandesha2/wsrm/AcksTo.java Thu Sep 29 21:18:32 2005
@@ -48,12 +48,12 @@
 	//private OMElement addressElement;
 
 	OMNamespace rmNamespace = SOAPAbstractFactory.getSOAPFactory(
-			Constants.DEFAULT_SOAP_VERSION).createOMNamespace(
+			Constants.SOAPVersion.DEFAULT).createOMNamespace(
 			Constants.WSRM.NS_URI_RM, Constants.WSRM.NS_PREFIX_RM);
 
 	public AcksTo() {
 		acksToElement = SOAPAbstractFactory.getSOAPFactory(
-				Constants.DEFAULT_SOAP_VERSION).createOMElement(
+				Constants.SOAPVersion.DEFAULT).createOMElement(
 				Constants.WSRM.ACKS_TO, rmNamespace);
 	}
 	
@@ -78,7 +78,7 @@
 		address.fromOMElement(acksToPart);
 
 		acksToElement = SOAPAbstractFactory.getSOAPFactory(
-				Constants.DEFAULT_SOAP_VERSION).createOMElement(
+				Constants.SOAPVersion.DEFAULT).createOMElement(
 				Constants.WSRM.ACKS_TO, rmNamespace);
 
 		return this;
@@ -98,7 +98,7 @@
 		element.addChild(acksToElement);
 
 		acksToElement = SOAPAbstractFactory.getSOAPFactory(
-				Constants.DEFAULT_SOAP_VERSION).createOMElement(
+				Constants.SOAPVersion.DEFAULT).createOMElement(
 				Constants.WSRM.ACKS_TO, rmNamespace);
 
 		return element;

Modified: webservices/sandesha/trunk/src/org/apache/sandesha2/wsrm/Address.java
URL: http://svn.apache.org/viewcvs/webservices/sandesha/trunk/src/org/apache/sandesha2/wsrm/Address.java?rev=292623&r1=292622&r2=292623&view=diff
==============================================================================
--- webservices/sandesha/trunk/src/org/apache/sandesha2/wsrm/Address.java (original)
+++ webservices/sandesha/trunk/src/org/apache/sandesha2/wsrm/Address.java Thu Sep 29 21:18:32 2005
@@ -31,13 +31,13 @@
 	OMElement addressElement;
 
 	OMNamespace rmNamespace = SOAPAbstractFactory.getSOAPFactory(
-			Constants.DEFAULT_SOAP_VERSION)
+			Constants.SOAPVersion.DEFAULT)
 			.createOMNamespace(Constants.WSA.NS_URI_ADDRESSING,
 					Constants.WSA.NS_PREFIX_ADDRESSING);
 
 	public Address() {
 		addressElement = SOAPAbstractFactory.getSOAPFactory(
-				Constants.DEFAULT_SOAP_VERSION).createOMElement(
+				Constants.SOAPVersion.DEFAULT).createOMElement(
 				Constants.WSA.ADDRESS, rmNamespace);
 	}
 	
@@ -61,7 +61,7 @@
 		addressElement = addressPart;
 		epr = new EndpointReference(addressText);
 		addressElement = SOAPAbstractFactory.getSOAPFactory(
-				Constants.DEFAULT_SOAP_VERSION).createOMElement(
+				Constants.SOAPVersion.DEFAULT).createOMElement(
 				Constants.WSA.ADDRESS, rmNamespace);
 		return this;
 
@@ -84,7 +84,7 @@
 		element.addChild(addressElement);
 
 		addressElement = SOAPAbstractFactory.getSOAPFactory(
-				Constants.DEFAULT_SOAP_VERSION).createOMElement(
+				Constants.SOAPVersion.DEFAULT).createOMElement(
 				Constants.WSA.ADDRESS, rmNamespace);
 
 		return element;

Modified: webservices/sandesha/trunk/src/org/apache/sandesha2/wsrm/CreateSequence.java
URL: http://svn.apache.org/viewcvs/webservices/sandesha/trunk/src/org/apache/sandesha2/wsrm/CreateSequence.java?rev=292623&r1=292622&r2=292623&view=diff
==============================================================================
--- webservices/sandesha/trunk/src/org/apache/sandesha2/wsrm/CreateSequence.java (original)
+++ webservices/sandesha/trunk/src/org/apache/sandesha2/wsrm/CreateSequence.java Thu Sep 29 21:18:32 2005
@@ -48,12 +48,12 @@
 	//private SequritytokenReference;
 
 	OMNamespace rmNamespace = SOAPAbstractFactory.getSOAPFactory(
-			Constants.DEFAULT_SOAP_VERSION).createOMNamespace(
+			Constants.SOAPVersion.DEFAULT).createOMNamespace(
 			Constants.WSRM.NS_URI_RM, Constants.WSRM.NS_PREFIX_RM);
 
 	public CreateSequence() {
 		createSequenceElement = SOAPAbstractFactory.getSOAPFactory(
-				Constants.DEFAULT_SOAP_VERSION).createOMElement(
+				Constants.SOAPVersion.DEFAULT).createOMElement(
 				Constants.WSRM.CREATE_SEQUENCE, rmNamespace);
 	}
 	
@@ -76,7 +76,7 @@
 					"Create sequence is not present in the passed element");
 
 		createSequenceElement = SOAPAbstractFactory.getSOAPFactory(
-				Constants.DEFAULT_SOAP_VERSION).createOMElement(
+				Constants.SOAPVersion.DEFAULT).createOMElement(
 				Constants.WSRM.CREATE_SEQUENCE, rmNamespace);
 
 		acksTo = new AcksTo();
@@ -125,7 +125,7 @@
 		soapBody.addChild(createSequenceElement);
 
 		createSequenceElement = SOAPAbstractFactory.getSOAPFactory(
-				Constants.DEFAULT_SOAP_VERSION).createOMElement(
+				Constants.SOAPVersion.DEFAULT).createOMElement(
 				Constants.WSRM.CREATE_SEQUENCE, rmNamespace);
 		return soapBody;
 	}

Modified: webservices/sandesha/trunk/src/org/apache/sandesha2/wsrm/CreateSequenceResponse.java
URL: http://svn.apache.org/viewcvs/webservices/sandesha/trunk/src/org/apache/sandesha2/wsrm/CreateSequenceResponse.java?rev=292623&r1=292622&r2=292623&view=diff
==============================================================================
--- webservices/sandesha/trunk/src/org/apache/sandesha2/wsrm/CreateSequenceResponse.java (original)
+++ webservices/sandesha/trunk/src/org/apache/sandesha2/wsrm/CreateSequenceResponse.java Thu Sep 29 21:18:32 2005
@@ -43,12 +43,12 @@
 	private Expires expires;
 
 	OMNamespace createSeqResNoNamespace = SOAPAbstractFactory.getSOAPFactory(
-			Constants.DEFAULT_SOAP_VERSION).createOMNamespace(
+			Constants.SOAPVersion.DEFAULT).createOMNamespace(
 			Constants.WSRM.NS_URI_RM, Constants.WSRM.NS_PREFIX_RM);
 
 	public CreateSequenceResponse() {
 		createSequenceResponseElement = SOAPAbstractFactory.getSOAPFactory(
-				Constants.DEFAULT_SOAP_VERSION).createOMElement(
+				Constants.SOAPVersion.DEFAULT).createOMElement(
 				Constants.WSRM.CREATE_SEQUENCE_RESPONSE,
 				createSeqResNoNamespace);
 	}
@@ -73,7 +73,7 @@
 					"The passed element does not contain a create seqence response part");
 
 		createSequenceResponseElement = SOAPAbstractFactory.getSOAPFactory(
-				Constants.DEFAULT_SOAP_VERSION).createOMElement(
+				Constants.SOAPVersion.DEFAULT).createOMElement(
 				Constants.WSRM.CREATE_SEQUENCE_RESPONSE,
 				createSeqResNoNamespace);
 
@@ -127,7 +127,7 @@
 		SOAPBody.addChild(createSequenceResponseElement);
 
 		createSequenceResponseElement = SOAPAbstractFactory.getSOAPFactory(
-				Constants.DEFAULT_SOAP_VERSION).createOMElement(
+				Constants.SOAPVersion.DEFAULT).createOMElement(
 				Constants.WSRM.CREATE_SEQUENCE_RESPONSE,
 				createSeqResNoNamespace);
 

Modified: webservices/sandesha/trunk/src/org/apache/sandesha2/wsrm/Expires.java
URL: http://svn.apache.org/viewcvs/webservices/sandesha/trunk/src/org/apache/sandesha2/wsrm/Expires.java?rev=292623&r1=292622&r2=292623&view=diff
==============================================================================
--- webservices/sandesha/trunk/src/org/apache/sandesha2/wsrm/Expires.java (original)
+++ webservices/sandesha/trunk/src/org/apache/sandesha2/wsrm/Expires.java Thu Sep 29 21:18:32 2005
@@ -35,7 +35,7 @@
 public class Expires implements IOMRMElement {
 
 	OMNamespace rmNamespace = SOAPAbstractFactory.getSOAPFactory(
-			Constants.DEFAULT_SOAP_VERSION).createOMNamespace(
+			Constants.SOAPVersion.DEFAULT).createOMNamespace(
 			Constants.WSRM.NS_URI_RM, Constants.WSRM.NS_PREFIX_RM);
 
 	OMElement expiresElement = null;
@@ -44,7 +44,7 @@
 
 	public Expires() {
 		expiresElement = SOAPAbstractFactory.getSOAPFactory(
-				Constants.DEFAULT_SOAP_VERSION).createOMElement(
+				Constants.SOAPVersion.DEFAULT).createOMElement(
 				Constants.WSRM.EXPIRES, rmNamespace);
 	}
 
@@ -59,7 +59,7 @@
 			throw new OMException("The duration value is not valid");
 
 		expiresElement = SOAPAbstractFactory.getSOAPFactory(
-				Constants.DEFAULT_SOAP_VERSION).createOMElement(
+				Constants.SOAPVersion.DEFAULT).createOMElement(
 				Constants.WSRM.EXPIRES, rmNamespace);
 
 		duration = expiresText;
@@ -82,7 +82,7 @@
 		element.addChild(expiresElement);
 
 		expiresElement = SOAPAbstractFactory.getSOAPFactory(
-				Constants.DEFAULT_SOAP_VERSION).createOMElement(
+				Constants.SOAPVersion.DEFAULT).createOMElement(
 				Constants.WSRM.EXPIRES, rmNamespace);
 
 		return element;

Modified: webservices/sandesha/trunk/src/org/apache/sandesha2/wsrm/FaultCode.java
URL: http://svn.apache.org/viewcvs/webservices/sandesha/trunk/src/org/apache/sandesha2/wsrm/FaultCode.java?rev=292623&r1=292622&r2=292623&view=diff
==============================================================================
--- webservices/sandesha/trunk/src/org/apache/sandesha2/wsrm/FaultCode.java (original)
+++ webservices/sandesha/trunk/src/org/apache/sandesha2/wsrm/FaultCode.java Thu Sep 29 21:18:32 2005
@@ -39,12 +39,12 @@
 	String faultCode = null;
 
 	OMNamespace rmNameSpace = SOAPAbstractFactory.getSOAPFactory(
-			Constants.DEFAULT_SOAP_VERSION).createOMNamespace(
+			Constants.SOAPVersion.DEFAULT).createOMNamespace(
 			Constants.WSRM.NS_URI_RM, Constants.WSRM.NS_PREFIX_RM);
 
 	public FaultCode() {
 		faultCodeElement = SOAPAbstractFactory.getSOAPFactory(
-				Constants.DEFAULT_SOAP_VERSION).createOMElement(
+				Constants.SOAPVersion.DEFAULT).createOMElement(
 				Constants.WSRM.FAULT_CODE, rmNameSpace);
 	}
 
@@ -69,7 +69,7 @@
 		this.faultCode = faultCodePart.getText();
 
 		faultCodeElement = SOAPAbstractFactory.getSOAPFactory(
-				Constants.DEFAULT_SOAP_VERSION).createOMElement(
+				Constants.SOAPVersion.DEFAULT).createOMElement(
 				Constants.WSRM.FAULT_CODE, rmNameSpace);
 
 		return sequenceFault;

Modified: webservices/sandesha/trunk/src/org/apache/sandesha2/wsrm/Identifier.java
URL: http://svn.apache.org/viewcvs/webservices/sandesha/trunk/src/org/apache/sandesha2/wsrm/Identifier.java?rev=292623&r1=292622&r2=292623&view=diff
==============================================================================
--- webservices/sandesha/trunk/src/org/apache/sandesha2/wsrm/Identifier.java (original)
+++ webservices/sandesha/trunk/src/org/apache/sandesha2/wsrm/Identifier.java Thu Sep 29 21:18:32 2005
@@ -42,12 +42,12 @@
 	private String identifier = null;
 
 	OMNamespace wsuNamespace = SOAPAbstractFactory.getSOAPFactory(
-			Constants.DEFAULT_SOAP_VERSION).createOMNamespace(
+			Constants.SOAPVersion.DEFAULT).createOMNamespace(
 			Constants.WSRM.NS_URI_RM, Constants.WSRM.NS_PREFIX_RM);
 
 	public Identifier() {
 		identifierElement = SOAPAbstractFactory.getSOAPFactory(
-				Constants.DEFAULT_SOAP_VERSION).createOMElement(
+				Constants.SOAPVersion.DEFAULT).createOMElement(
 				Constants.WSRM.IDENTIFIER, wsuNamespace);
 	}
 
@@ -70,7 +70,7 @@
 			throw new OMException(
 					"The parsed element does not contain an identifier part");
 		identifierElement = SOAPAbstractFactory.getSOAPFactory(
-				Constants.DEFAULT_SOAP_VERSION).createOMElement(
+				Constants.SOAPVersion.DEFAULT).createOMElement(
 				Constants.WSRM.IDENTIFIER, wsuNamespace);
 
 		String identifierText = identifierPart.getText();
@@ -91,7 +91,7 @@
 		element.addChild(identifierElement);
 
 		identifierElement = SOAPAbstractFactory.getSOAPFactory(
-				Constants.DEFAULT_SOAP_VERSION).createOMElement(
+				Constants.SOAPVersion.DEFAULT).createOMElement(
 				Constants.WSRM.IDENTIFIER, wsuNamespace);
 
 		return element;

Modified: webservices/sandesha/trunk/src/org/apache/sandesha2/wsrm/LastMessage.java
URL: http://svn.apache.org/viewcvs/webservices/sandesha/trunk/src/org/apache/sandesha2/wsrm/LastMessage.java?rev=292623&r1=292622&r2=292623&view=diff
==============================================================================
--- webservices/sandesha/trunk/src/org/apache/sandesha2/wsrm/LastMessage.java (original)
+++ webservices/sandesha/trunk/src/org/apache/sandesha2/wsrm/LastMessage.java Thu Sep 29 21:18:32 2005
@@ -40,12 +40,12 @@
 	private OMElement lastMessageElement;
 
 	OMNamespace lastMsgNamespace = SOAPAbstractFactory.getSOAPFactory(
-			Constants.DEFAULT_SOAP_VERSION).createOMNamespace(
+			Constants.SOAPVersion.DEFAULT).createOMNamespace(
 			Constants.WSRM.NS_URI_RM, Constants.WSRM.NS_PREFIX_RM);
 
 	public LastMessage() {
 		lastMessageElement = SOAPAbstractFactory.getSOAPFactory(
-				Constants.DEFAULT_SOAP_VERSION).createOMElement(
+				Constants.SOAPVersion.DEFAULT).createOMElement(
 				Constants.WSRM.LAST_MSG, lastMsgNamespace);
 	}
 
@@ -61,7 +61,7 @@
 					"The passed element does not contain a Last Message part");
 
 		lastMessageElement = SOAPAbstractFactory.getSOAPFactory(
-				Constants.DEFAULT_SOAP_VERSION).createOMElement(
+				Constants.SOAPVersion.DEFAULT).createOMElement(
 				Constants.WSRM.LAST_MSG, lastMsgNamespace);
 
 		return this;
@@ -75,7 +75,7 @@
 		sequenceElement.addChild(lastMessageElement);
 
 		lastMessageElement = SOAPAbstractFactory.getSOAPFactory(
-				Constants.DEFAULT_SOAP_VERSION).createOMElement(
+				Constants.SOAPVersion.DEFAULT).createOMElement(
 				Constants.WSRM.LAST_MSG, lastMsgNamespace);
 
 		return sequenceElement;

Modified: webservices/sandesha/trunk/src/org/apache/sandesha2/wsrm/MessageNumber.java
URL: http://svn.apache.org/viewcvs/webservices/sandesha/trunk/src/org/apache/sandesha2/wsrm/MessageNumber.java?rev=292623&r1=292622&r2=292623&view=diff
==============================================================================
--- webservices/sandesha/trunk/src/org/apache/sandesha2/wsrm/MessageNumber.java (original)
+++ webservices/sandesha/trunk/src/org/apache/sandesha2/wsrm/MessageNumber.java Thu Sep 29 21:18:32 2005
@@ -42,10 +42,10 @@
 	private OMElement messageNoElement;
 	
 	OMNamespace msgNoNamespace =
-		SOAPAbstractFactory.getSOAPFactory(Constants.DEFAULT_SOAP_VERSION).createOMNamespace(Constants.WSRM.NS_URI_RM, Constants.WSRM.NS_PREFIX_RM);
+		SOAPAbstractFactory.getSOAPFactory(Constants.SOAPVersion.DEFAULT).createOMNamespace(Constants.WSRM.NS_URI_RM, Constants.WSRM.NS_PREFIX_RM);
 	
 	public MessageNumber(){
-		messageNoElement = SOAPAbstractFactory.getSOAPFactory(Constants.DEFAULT_SOAP_VERSION).createOMElement(Constants.WSRM.MSG_NUMBER,msgNoNamespace);
+		messageNoElement = SOAPAbstractFactory.getSOAPFactory(Constants.SOAPVersion.DEFAULT).createOMElement(Constants.WSRM.MSG_NUMBER,msgNoNamespace);
 	}
 	
 	public long getMessageNumber(){
@@ -61,7 +61,7 @@
 		if (msgNumberPart==null)
 			throw new OMException ("The passed sequnce element does not contain a message number part");
 		
-		messageNoElement = SOAPAbstractFactory.getSOAPFactory(Constants.DEFAULT_SOAP_VERSION).createOMElement(Constants.WSRM.MSG_NUMBER,msgNoNamespace);
+		messageNoElement = SOAPAbstractFactory.getSOAPFactory(Constants.SOAPVersion.DEFAULT).createOMElement(Constants.WSRM.MSG_NUMBER,msgNoNamespace);
 
 		String msgNoStr = msgNumberPart.getText();
 		messageNumber = Long.parseLong(msgNoStr);
@@ -76,7 +76,7 @@
 		messageNoElement.setText(Long.toString(messageNumber));
 		element.addChild(messageNoElement);
 		
-		messageNoElement = SOAPAbstractFactory.getSOAPFactory(Constants.DEFAULT_SOAP_VERSION).createOMElement(Constants.WSRM.MSG_NUMBER,msgNoNamespace);
+		messageNoElement = SOAPAbstractFactory.getSOAPFactory(Constants.SOAPVersion.DEFAULT).createOMElement(Constants.WSRM.MSG_NUMBER,msgNoNamespace);
 		
 		return element;
 	}

Modified: webservices/sandesha/trunk/src/org/apache/sandesha2/wsrm/Nack.java
URL: http://svn.apache.org/viewcvs/webservices/sandesha/trunk/src/org/apache/sandesha2/wsrm/Nack.java?rev=292623&r1=292622&r2=292623&view=diff
==============================================================================
--- webservices/sandesha/trunk/src/org/apache/sandesha2/wsrm/Nack.java (original)
+++ webservices/sandesha/trunk/src/org/apache/sandesha2/wsrm/Nack.java Thu Sep 29 21:18:32 2005
@@ -40,10 +40,10 @@
 	private long nackNumber;
 	
 	OMNamespace rmNamespace =
-		SOAPAbstractFactory.getSOAPFactory(Constants.DEFAULT_SOAP_VERSION).createOMNamespace(Constants.WSRM.NS_URI_RM, Constants.WSRM.NS_PREFIX_RM);
+		SOAPAbstractFactory.getSOAPFactory(Constants.SOAPVersion.DEFAULT).createOMNamespace(Constants.WSRM.NS_URI_RM, Constants.WSRM.NS_PREFIX_RM);
 	
 	public Nack(){
-		nackElement = SOAPAbstractFactory.getSOAPFactory(Constants.DEFAULT_SOAP_VERSION).createOMElement(
+		nackElement = SOAPAbstractFactory.getSOAPFactory(Constants.SOAPVersion.DEFAULT).createOMElement(
 				Constants.WSRM.NACK,rmNamespace);
 	}
 	
@@ -65,7 +65,7 @@
 			throw new OMException ("Nack element does not contain a valid long value");
 		}
 		
-		nackElement = SOAPAbstractFactory.getSOAPFactory(Constants.DEFAULT_SOAP_VERSION).createOMElement(
+		nackElement = SOAPAbstractFactory.getSOAPFactory(Constants.SOAPVersion.DEFAULT).createOMElement(
 				Constants.WSRM.NACK,rmNamespace);
 		
 		return this;
@@ -84,7 +84,7 @@
 		nackElement.setText(Long.toString(nackNumber));
 		sequenceAckElement.addChild(nackElement);
 
-		nackElement = SOAPAbstractFactory.getSOAPFactory(Constants.DEFAULT_SOAP_VERSION).createOMElement(
+		nackElement = SOAPAbstractFactory.getSOAPFactory(Constants.SOAPVersion.DEFAULT).createOMElement(
 				Constants.WSRM.NACK,rmNamespace);
 		
 		return sequenceAckElement;

Modified: webservices/sandesha/trunk/src/org/apache/sandesha2/wsrm/Sequence.java
URL: http://svn.apache.org/viewcvs/webservices/sandesha/trunk/src/org/apache/sandesha2/wsrm/Sequence.java?rev=292623&r1=292622&r2=292623&view=diff
==============================================================================
--- webservices/sandesha/trunk/src/org/apache/sandesha2/wsrm/Sequence.java (original)
+++ webservices/sandesha/trunk/src/org/apache/sandesha2/wsrm/Sequence.java Thu Sep 29 21:18:32 2005
@@ -48,12 +48,12 @@
 	private LastMessage lastMessage = null;
 
 	OMNamespace seqNoNamespace = SOAPAbstractFactory.getSOAPFactory(
-			Constants.DEFAULT_SOAP_VERSION).createOMNamespace(
+			Constants.SOAPVersion.DEFAULT).createOMNamespace(
 			Constants.WSRM.NS_URI_RM, Constants.WSRM.NS_PREFIX_RM);
 
 	public Sequence() {
 		sequenceElement = SOAPAbstractFactory.getSOAPFactory(
-				Constants.DEFAULT_SOAP_VERSION).createOMElement(
+				Constants.SOAPVersion.DEFAULT).createOMElement(
 				Constants.WSRM.SEQUENCE, seqNoNamespace);
 	}
 
@@ -76,7 +76,7 @@
 					"Cannot find Sequence element in the given element");
 
 		sequenceElement = SOAPAbstractFactory.getSOAPFactory(
-				Constants.DEFAULT_SOAP_VERSION).createOMElement(
+				Constants.SOAPVersion.DEFAULT).createOMElement(
 				Constants.WSRM.SEQUENCE, seqNoNamespace);
 
 		identifier = new Identifier();
@@ -129,7 +129,7 @@
 		//resetting the element. So that subsequest toOMElement calls will
 		// attach a different object.
 		sequenceElement = SOAPAbstractFactory.getSOAPFactory(
-				Constants.DEFAULT_SOAP_VERSION).createOMElement(
+				Constants.SOAPVersion.DEFAULT).createOMElement(
 				Constants.WSRM.SEQUENCE, seqNoNamespace);
 
 		return headerElement;

Modified: webservices/sandesha/trunk/src/org/apache/sandesha2/wsrm/SequenceAcknowledgement.java
URL: http://svn.apache.org/viewcvs/webservices/sandesha/trunk/src/org/apache/sandesha2/wsrm/SequenceAcknowledgement.java?rev=292623&r1=292622&r2=292623&view=diff
==============================================================================
--- webservices/sandesha/trunk/src/org/apache/sandesha2/wsrm/SequenceAcknowledgement.java (original)
+++ webservices/sandesha/trunk/src/org/apache/sandesha2/wsrm/SequenceAcknowledgement.java Thu Sep 29 21:18:32 2005
@@ -51,12 +51,12 @@
 	private List nackList;
 
 	OMNamespace rmNamespace = SOAPAbstractFactory.getSOAPFactory(
-			Constants.DEFAULT_SOAP_VERSION).createOMNamespace(
+			Constants.SOAPVersion.DEFAULT).createOMNamespace(
 			Constants.WSRM.NS_URI_RM, Constants.WSRM.NS_PREFIX_RM);
 
 	public SequenceAcknowledgement() {
 		sequenceAcknowledgementElement = SOAPAbstractFactory.getSOAPFactory(
-				Constants.DEFAULT_SOAP_VERSION).createOMElement(
+				Constants.SOAPVersion.DEFAULT).createOMElement(
 				Constants.WSRM.SEQUENCE_ACK, rmNamespace);
 		acknowledgementRangeList = new LinkedList();
 		nackList = new LinkedList();
@@ -105,7 +105,7 @@
 		}
 
 		sequenceAcknowledgementElement = SOAPAbstractFactory.getSOAPFactory(
-				Constants.DEFAULT_SOAP_VERSION).createOMElement(
+				Constants.SOAPVersion.DEFAULT).createOMElement(
 				Constants.WSRM.SEQUENCE_ACK, rmNamespace);
 
 		return this;
@@ -144,7 +144,7 @@
 		SOAPHeader.addChild(sequenceAcknowledgementElement);
 
 		sequenceAcknowledgementElement = SOAPAbstractFactory.getSOAPFactory(
-				Constants.DEFAULT_SOAP_VERSION).createOMElement(
+				Constants.SOAPVersion.DEFAULT).createOMElement(
 				Constants.WSRM.SEQUENCE_ACK, rmNamespace);
 
 		return header;

Modified: webservices/sandesha/trunk/src/org/apache/sandesha2/wsrm/SequenceFault.java
URL: http://svn.apache.org/viewcvs/webservices/sandesha/trunk/src/org/apache/sandesha2/wsrm/SequenceFault.java?rev=292623&r1=292622&r2=292623&view=diff
==============================================================================
--- webservices/sandesha/trunk/src/org/apache/sandesha2/wsrm/SequenceFault.java (original)
+++ webservices/sandesha/trunk/src/org/apache/sandesha2/wsrm/SequenceFault.java Thu Sep 29 21:18:32 2005
@@ -44,12 +44,12 @@
 	private FaultCode faultCode;
 
 	OMNamespace rmNamespace = SOAPAbstractFactory.getSOAPFactory(
-			Constants.DEFAULT_SOAP_VERSION).createOMNamespace(
+			Constants.SOAPVersion.DEFAULT).createOMNamespace(
 			Constants.WSRM.NS_URI_RM, Constants.WSRM.NS_PREFIX_RM);
 
 	public SequenceFault() {
 		sequenceFaultElement = SOAPAbstractFactory.getSOAPFactory(
-				Constants.DEFAULT_SOAP_VERSION).createOMElement(
+				Constants.SOAPVersion.DEFAULT).createOMElement(
 				Constants.WSRM.SEQUENCE_FAULT, rmNamespace);
 	}
 
@@ -80,7 +80,7 @@
 		}
 
 		sequenceFaultElement = SOAPAbstractFactory.getSOAPFactory(
-				Constants.DEFAULT_SOAP_VERSION).createOMElement(
+				Constants.SOAPVersion.DEFAULT).createOMElement(
 				Constants.WSRM.SEQUENCE_FAULT, rmNamespace);
 
 		return this;
@@ -103,7 +103,7 @@
 		body.addChild(sequenceFaultElement);
 
 		sequenceFaultElement = SOAPAbstractFactory.getSOAPFactory(
-				Constants.DEFAULT_SOAP_VERSION).createOMElement(
+				Constants.SOAPVersion.DEFAULT).createOMElement(
 				Constants.WSRM.SEQUENCE_FAULT, rmNamespace);
 
 		return body;

Modified: webservices/sandesha/trunk/src/org/apache/sandesha2/wsrm/SequenceOffer.java
URL: http://svn.apache.org/viewcvs/webservices/sandesha/trunk/src/org/apache/sandesha2/wsrm/SequenceOffer.java?rev=292623&r1=292622&r2=292623&view=diff
==============================================================================
--- webservices/sandesha/trunk/src/org/apache/sandesha2/wsrm/SequenceOffer.java (original)
+++ webservices/sandesha/trunk/src/org/apache/sandesha2/wsrm/SequenceOffer.java Thu Sep 29 21:18:32 2005
@@ -40,12 +40,12 @@
 	private Expires expires = null;
 
 	OMNamespace rmNamespace = SOAPAbstractFactory.getSOAPFactory(
-			Constants.DEFAULT_SOAP_VERSION).createOMNamespace(
+			Constants.SOAPVersion.DEFAULT).createOMNamespace(
 			Constants.WSRM.NS_URI_RM, Constants.WSRM.NS_PREFIX_RM);
 
 	public SequenceOffer() {
 		sequenceOfferElement = SOAPAbstractFactory.getSOAPFactory(
-				Constants.DEFAULT_SOAP_VERSION).createOMElement(
+				Constants.SOAPVersion.DEFAULT).createOMElement(
 				Constants.WSRM.SEQUENCE_OFFER, rmNamespace);
 	}
 
@@ -63,7 +63,7 @@
 					"The passed element does not contain a SequenceOffer part");
 
 		sequenceOfferElement = SOAPAbstractFactory.getSOAPFactory(
-				Constants.DEFAULT_SOAP_VERSION).createOMElement(
+				Constants.SOAPVersion.DEFAULT).createOMElement(
 				Constants.WSRM.SEQUENCE_OFFER, rmNamespace);
 
 		identifier = new Identifier();
@@ -98,7 +98,7 @@
 		createSequenceElement.addChild(sequenceOfferElement);
 
 		sequenceOfferElement = SOAPAbstractFactory.getSOAPFactory(
-				Constants.DEFAULT_SOAP_VERSION).createOMElement(
+				Constants.SOAPVersion.DEFAULT).createOMElement(
 				Constants.WSRM.SEQUENCE_OFFER, rmNamespace);
 
 		return createSequenceElement;

Modified: webservices/sandesha/trunk/src/org/apache/sandesha2/wsrm/TerminateSequence.java
URL: http://svn.apache.org/viewcvs/webservices/sandesha/trunk/src/org/apache/sandesha2/wsrm/TerminateSequence.java?rev=292623&r1=292622&r2=292623&view=diff
==============================================================================
--- webservices/sandesha/trunk/src/org/apache/sandesha2/wsrm/TerminateSequence.java (original)
+++ webservices/sandesha/trunk/src/org/apache/sandesha2/wsrm/TerminateSequence.java Thu Sep 29 21:18:32 2005
@@ -40,12 +40,12 @@
 	private Identifier identifier;
 
 	OMNamespace rmNameSpace = SOAPAbstractFactory.getSOAPFactory(
-			Constants.DEFAULT_SOAP_VERSION).createOMNamespace(
+			Constants.SOAPVersion.DEFAULT).createOMNamespace(
 			Constants.WSRM.NS_URI_RM, Constants.WSRM.NS_PREFIX_RM);
 
 	public TerminateSequence() {
 		terminateSequenceElement = SOAPAbstractFactory.getSOAPFactory(
-				Constants.DEFAULT_SOAP_VERSION).createOMElement(
+				Constants.SOAPVersion.DEFAULT).createOMElement(
 				Constants.WSRM.TERMINATE_SEQUENCE, rmNameSpace);
 	}
 
@@ -70,7 +70,7 @@
 		identifier.fromOMElement(terminateSeqPart);
 
 		terminateSequenceElement = SOAPAbstractFactory.getSOAPFactory(
-				Constants.DEFAULT_SOAP_VERSION).createOMElement(
+				Constants.SOAPVersion.DEFAULT).createOMElement(
 				Constants.WSRM.TERMINATE_SEQUENCE, rmNameSpace);
 
 		return this;
@@ -94,7 +94,7 @@
 		body.addChild(terminateSequenceElement);
 
 		terminateSequenceElement = SOAPAbstractFactory.getSOAPFactory(
-				Constants.DEFAULT_SOAP_VERSION).createOMElement(
+				Constants.SOAPVersion.DEFAULT).createOMElement(
 				Constants.WSRM.TERMINATE_SEQUENCE, rmNameSpace);
 
 		return body;



---------------------------------------------------------------------
To unsubscribe, e-mail: sandesha-dev-unsubscribe@ws.apache.org
For additional commands, e-mail: sandesha-dev-help@ws.apache.org