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/11/30 07:05:22 UTC

svn commit: r349889 [1/2] - in /webservices/sandesha/trunk/src/org/apache/sandesha2: ./ handlers/ msgprocessors/ policy/ storage/beans/ storage/inmemory/ util/ workers/ wsrm/

Author: chamikara
Date: Tue Nov 29 22:03:23 2005
New Revision: 349889

URL: http://svn.apache.org/viewcvs?rev=349889&view=rev
Log:
Renamed the constants class to Sandesha2Constants.
Refactored and cleaned the Sandesha2Constants class.

Added:
    webservices/sandesha/trunk/src/org/apache/sandesha2/Sandesha2Constants.java
Removed:
    webservices/sandesha/trunk/src/org/apache/sandesha2/Constants.java
Modified:
    webservices/sandesha/trunk/src/org/apache/sandesha2/AcknowledgementManager.java
    webservices/sandesha/trunk/src/org/apache/sandesha2/RMMsgContext.java
    webservices/sandesha/trunk/src/org/apache/sandesha2/SOAPFaultEnvelopeCreator.java
    webservices/sandesha/trunk/src/org/apache/sandesha2/TerminateManager.java
    webservices/sandesha/trunk/src/org/apache/sandesha2/handlers/SandeshaGlobalInHandler.java
    webservices/sandesha/trunk/src/org/apache/sandesha2/handlers/SandeshaInHandler.java
    webservices/sandesha/trunk/src/org/apache/sandesha2/handlers/SandeshaOutHandler.java
    webservices/sandesha/trunk/src/org/apache/sandesha2/msgprocessors/AcknowledgementProcessor.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/CreateSeqResponseMsgProcessor.java
    webservices/sandesha/trunk/src/org/apache/sandesha2/msgprocessors/MsgProcessorFactory.java
    webservices/sandesha/trunk/src/org/apache/sandesha2/msgprocessors/TerminateSeqMsgProcessor.java
    webservices/sandesha/trunk/src/org/apache/sandesha2/policy/RMPolicyBean.java
    webservices/sandesha/trunk/src/org/apache/sandesha2/storage/beans/SenderBean.java
    webservices/sandesha/trunk/src/org/apache/sandesha2/storage/beans/SequencePropertyBean.java
    webservices/sandesha/trunk/src/org/apache/sandesha2/storage/inmemory/InMemoryCreateSeqBeanMgr.java
    webservices/sandesha/trunk/src/org/apache/sandesha2/storage/inmemory/InMemoryInvokerBeanMgr.java
    webservices/sandesha/trunk/src/org/apache/sandesha2/storage/inmemory/InMemoryNextMsgBeanMgr.java
    webservices/sandesha/trunk/src/org/apache/sandesha2/storage/inmemory/InMemorySenderBeanMgr.java
    webservices/sandesha/trunk/src/org/apache/sandesha2/storage/inmemory/InMemorySequencePropertyBeanMgr.java
    webservices/sandesha/trunk/src/org/apache/sandesha2/util/FaultManager.java
    webservices/sandesha/trunk/src/org/apache/sandesha2/util/MessageRetransmissionAdjuster.java
    webservices/sandesha/trunk/src/org/apache/sandesha2/util/MsgInitializer.java
    webservices/sandesha/trunk/src/org/apache/sandesha2/util/PropertyManager.java
    webservices/sandesha/trunk/src/org/apache/sandesha2/util/RMMsgCreator.java
    webservices/sandesha/trunk/src/org/apache/sandesha2/util/SOAPAbstractFactory.java
    webservices/sandesha/trunk/src/org/apache/sandesha2/util/SandeshaPropertyBean.java
    webservices/sandesha/trunk/src/org/apache/sandesha2/util/SandeshaUtil.java
    webservices/sandesha/trunk/src/org/apache/sandesha2/util/SequenceManager.java
    webservices/sandesha/trunk/src/org/apache/sandesha2/workers/InOrderInvoker.java
    webservices/sandesha/trunk/src/org/apache/sandesha2/workers/Sender.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/RMElements.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/AcknowledgementManager.java
URL: http://svn.apache.org/viewcvs/webservices/sandesha/trunk/src/org/apache/sandesha2/AcknowledgementManager.java?rev=349889&r1=349888&r2=349889&view=diff
==============================================================================
--- webservices/sandesha/trunk/src/org/apache/sandesha2/AcknowledgementManager.java (original)
+++ webservices/sandesha/trunk/src/org/apache/sandesha2/AcknowledgementManager.java Tue Nov 29 22:03:23 2005
@@ -60,7 +60,7 @@
 		SenderBean findBean = new SenderBean();
 
 		Sequence sequence = (Sequence) applicationRMMsgContext
-				.getMessagePart(Constants.MessageParts.SEQUENCE);
+				.getMessagePart(Sandesha2Constants.MessageParts.SEQUENCE);
 		if (sequence == null)
 			throw new SandeshaException(
 					"Application message does not contain a sequence part");
@@ -69,13 +69,13 @@
 
 		SequencePropertyBean internalSequenceBean = sequencePropertyBeanMgr
 				.retrieve(sequenceId,
-						Constants.SequenceProperties.INTERNAL_SEQUENCE_ID);
+						Sandesha2Constants.SequenceProperties.INTERNAL_SEQUENCE_ID);
 		if (internalSequenceBean == null)
 			throw new SandeshaException("Temp Sequence is not set");
 
 		String internalSequenceId = (String) internalSequenceBean.getValue();
 		findBean.setInternalSequenceId(internalSequenceId);
-		findBean.setMessagetype(Constants.MessageTypes.ACK);
+		findBean.setMessagetype(Sandesha2Constants.MessageTypes.ACK);
 
 		Collection collection = retransmitterBeanMgr.find(findBean);
 		Iterator it = collection.iterator();
@@ -91,13 +91,13 @@
 					.getStoredMessageContext(ackBean.getKey());
 			RMMsgContext ackRMMsgContext = MsgInitializer
 					.initializeMessage(ackMsgContext);
-			if (ackRMMsgContext.getMessageType() != Constants.MessageTypes.ACK)
+			if (ackRMMsgContext.getMessageType() != Sandesha2Constants.MessageTypes.ACK)
 				throw new SandeshaException("Invalid ack message entry");
 
 			SequenceAcknowledgement sequenceAcknowledgement = (SequenceAcknowledgement) ackRMMsgContext
-					.getMessagePart(Constants.MessageParts.SEQ_ACKNOWLEDGEMENT);
+					.getMessagePart(Sandesha2Constants.MessageParts.SEQ_ACKNOWLEDGEMENT);
 			applicationRMMsgContext.setMessagePart(
-					Constants.MessageParts.SEQ_ACKNOWLEDGEMENT,
+					Sandesha2Constants.MessageParts.SEQ_ACKNOWLEDGEMENT,
 					sequenceAcknowledgement);
 
 			applicationRMMsgContext.addSOAPEnvelope();

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=349889&r1=349888&r2=349889&view=diff
==============================================================================
--- webservices/sandesha/trunk/src/org/apache/sandesha2/RMMsgContext.java (original)
+++ webservices/sandesha/trunk/src/org/apache/sandesha2/RMMsgContext.java Tue Nov 29 22:03:23 2005
@@ -53,7 +53,7 @@
 
 	public RMMsgContext() {
 		rmMessageParts = new HashMap();
-		messageType = Constants.MessageTypes.UNKNOWN;
+		messageType = Sandesha2Constants.MessageTypes.UNKNOWN;
 	}
 
 	public void setMessageContext(MessageContext msgCtx) {
@@ -72,10 +72,10 @@
 	 * @throws SandeshaException
 	 */
 	public void addSOAPEnvelope() throws SandeshaException {
-		int SOAPVersion = Constants.SOAPVersion.v1_1;
+		int SOAPVersion = Sandesha2Constants.SOAPVersion.v1_1;
 
 		if (!msgContext.isSOAP11())
-			SOAPVersion = Constants.SOAPVersion.v1_2;
+			SOAPVersion = Sandesha2Constants.SOAPVersion.v1_2;
 
 		if (msgContext.getEnvelope() == null) {
 			try {
@@ -107,7 +107,7 @@
 	 * @param msgType
 	 */
 	public void setMessageType(int msgType) {
-		if (msgType >= 0 && msgType <= Constants.MessageTypes.MAX_MESSAGE_TYPE)
+		if (msgType >= 0 && msgType <= Sandesha2Constants.MessageTypes.MAX_MESSAGE_TYPE)
 			this.messageType = msgType;
 	}
 
@@ -120,7 +120,7 @@
 	 * @param part
 	 */
 	public void setMessagePart(int partId, IOMRMPart part) {
-		if (partId >= 0 && partId <= Constants.MessageParts.MAX_MSG_PART_ID)
+		if (partId >= 0 && partId <= Sandesha2Constants.MessageParts.MAX_MSG_PART_ID)
 			rmMessageParts.put(new Integer(partId), part);
 	}
 

Modified: webservices/sandesha/trunk/src/org/apache/sandesha2/SOAPFaultEnvelopeCreator.java
URL: http://svn.apache.org/viewcvs/webservices/sandesha/trunk/src/org/apache/sandesha2/SOAPFaultEnvelopeCreator.java?rev=349889&r1=349888&r2=349889&view=diff
==============================================================================
--- webservices/sandesha/trunk/src/org/apache/sandesha2/SOAPFaultEnvelopeCreator.java (original)
+++ webservices/sandesha/trunk/src/org/apache/sandesha2/SOAPFaultEnvelopeCreator.java Tue Nov 29 22:03:23 2005
@@ -66,7 +66,7 @@
 			throw new SandeshaException(e.getMessage());
 		}
 
-		if (SOAPVersion == Constants.SOAPVersion.v1_1)
+		if (SOAPVersion == Sandesha2Constants.SOAPVersion.v1_1)
 			doSOAP11Encoding(faultMsgContext, faultData);
 		else
 			doSOAP12Encoding(faultMsgContext, faultData);
@@ -89,10 +89,10 @@
 		if (faultType <= 0)
 			return false;
 
-		if (faultType == Constants.SOAPFaults.FaultType.CREATE_SEQUENCE_REFUSED)
+		if (faultType == Sandesha2Constants.SOAPFaults.FaultType.CREATE_SEQUENCE_REFUSED)
 			sequenceFault = true;
 
-		if (faultType == Constants.SOAPFaults.FaultType.UNKNOWN_SEQUENCE)
+		if (faultType == Sandesha2Constants.SOAPFaults.FaultType.UNKNOWN_SEQUENCE)
 			sequenceFault = true;
 
 		return sequenceFault;
@@ -202,7 +202,7 @@
 		if (detailElement != null)
 			faultDetail.addChild(detailElement);
 
-		faultMsgContext.setWSAAction(Constants.WSA.SOAP_FAULT_ACTION);
+		faultMsgContext.setWSAAction(Sandesha2Constants.WSA.SOAP_FAULT_ACTION);
 	}
 
 }

Added: webservices/sandesha/trunk/src/org/apache/sandesha2/Sandesha2Constants.java
URL: http://svn.apache.org/viewcvs/webservices/sandesha/trunk/src/org/apache/sandesha2/Sandesha2Constants.java?rev=349889&view=auto
==============================================================================
--- webservices/sandesha/trunk/src/org/apache/sandesha2/Sandesha2Constants.java (added)
+++ webservices/sandesha/trunk/src/org/apache/sandesha2/Sandesha2Constants.java Tue Nov 29 22:03:23 2005
@@ -0,0 +1,327 @@
+/*
+ * Copyright  1999-2004 The Apache Software Foundation.
+ *
+ *  Licensed under the Apache License, Version 2.0 (the "License");
+ *  you may not use this file except in compliance with the License.
+ *  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ *  Unless required by applicable law or agreed to in writing, software
+ *  distributed under the License is distributed on an "AS IS" BASIS,
+ *  WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ *  See the License for the specific language governing permissions and
+ *  limitations under the License.
+ *
+ */
+
+package org.apache.sandesha2;
+
+/**
+ * Contains all the Sandesha2Constants of Sandesha2.
+ * Please see sub-interfaces to see grouped data.
+ * 
+ * @author Chamikara Jayalath <ch...@gmail.com>
+ * @author Sanka Samaranayaka <ss...@gmail.com>
+ * @author Jaliya Ekanayaka <ja...@opensource.lk>
+ */
+
+public interface Sandesha2Constants {
+
+	public interface WSRM {
+		String NS_PREFIX_RM = "wsrm";
+
+		String NS_URI_RM = "http://schemas.xmlsoap.org/ws/2005/02/rm";
+
+		String MSG_NUMBER = "MessageNumber";
+
+		String LAST_MSG = "LastMessage";
+
+		String SEQUENCE = "Sequence";
+
+		String SEQUENCE_OFFER = "Offer";
+
+		String TERMINATE_SEQUENCE = "TerminateSequence";
+
+		String FAULT_CODE = "FaultCode";
+
+		String SEQUENCE_FAULT = "SequenceFault";
+
+		String ACKS_TO = "AcksTo";
+
+		String EXPIRES = "Expires";
+
+		String CREATE_SEQUENCE = "CreateSequence";
+
+		String CREATE_SEQUENCE_RESPONSE = "CreateSequenceResponse";
+
+		String ACK_REQUESTED = "AckRequested";
+
+		String ACK_RANGE = "AcknowledgementRange";
+
+		String UPPER = "Upper";
+
+		String LOWER = "Lower";
+
+		String NACK = "Nack";
+
+		String SEQUENCE_ACK = "SequenceAcknowledgement";
+
+		String IDENTIFIER = "Identifier";
+
+		String ACCEPT = "Accept";
+
+		public interface Actions {
+
+			String ACTION_CREATE_SEQUENCE = "http://schemas.xmlsoap.org/ws/2005/02/rm/CreateSequence";
+
+			String ACTION_CREATE_SEQUENCE_RESPONSE = "http://schemas.xmlsoap.org/ws/2005/02/rm/CreateSequenceResponse";
+
+			String ACTION_SEQUENCE_ACKNOWLEDGEMENT = "http://schemas.xmlsoap.org/ws/2005/02/rm/SequenceAcknowledgement";
+
+			String ACTION_TERMINATE_SEQUENCE = "http://schemas.xmlsoap.org/ws/2005/02/rm/TerminateSequence";
+
+			String SOAP_ACTION_CREATE_SEQUENCE = "http://schemas.xmlsoap.org/ws/2005/02/rm/CreateSequence";
+
+			String SOAP_ACTION_CREATE_SEQUENCE_RESPONSE = "http://schemas.xmlsoap.org/ws/2005/02/rm/CreateSequenceResponse";
+
+			String SOAP_ACTION_SEQUENCE_ACKNOWLEDGEMENT = "http://schemas.xmlsoap.org/ws/2005/02/rm/SequenceAcknowledgement";
+
+			String SOAP_ACTION_TERMINATE_SEQUENCE = "http://schemas.xmlsoap.org/ws/2005/02/rm/TerminateSequence";
+
+		}
+	}
+
+	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";
+
+		String SOAP_FAULT_ACTION = "http://schemas.xmlsoap.org/ws/2004/08/addressing/fault";
+	}
+
+	public interface WSP {
+		String RM_POLICY_BEAN = "RMPolicyBean";
+	}
+
+	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;
+
+		int SEQUENCE = 6;
+
+		int SEQ_ACKNOWLEDGEMENT = 7;
+
+		int ADDR_HEADERS = 8;
+
+		int CREATE_SEQ = 9;
+
+		int CREATE_SEQ_RESPONSE = 10;
+
+		int TERMINATE_SEQ = 11;
+
+		int ACK_REQUEST = 12;
+
+		int MAX_MSG_PART_ID = 13;
+	}
+
+	public interface SequenceProperties {
+
+		String ALL_SEQUENCES = "AllSequences"; //this is not a sequence
+											   // property. This is used as the
+											   // sequenceId to share data b/w
+											   // sequences
+
+		String RECEIVED_MESSAGES = "SeqMsgListProperty";
+
+		String TO_EPR = "ToEPR";
+
+		String ACKS_TO_EPR = "acksToEPR";
+
+		String OUT_SEQUENCE_ID = "OutSequenceId";
+
+		String INTERNAL_SEQUENCE_ID = "TempSequenceId";
+
+		String REPLY_TO_EPR = "ReplyToEPR";
+
+		String APP_MSG_PROCESSOR_LIST = "AppMsgProcessorList";
+
+		String OUT_CREATE_SEQUENCE_SENT = "OutCreateSeqSent";
+
+		String NEXT_MESSAGE_NUMBER = "NextMsgNo";
+
+		String LAST_OUT_MESSAGE = "LastOutMessage";
+
+		String INCOMING_SEQUENCE_LIST = "IncomingSequenceList";
+
+		String CHECK_RESPONSE = "CheckResponse";
+
+		String OFFERED_SEQUENCE = "OfferedSequence";
+
+		String TERMINATE_ADDED = "TerminateAdded";
+	}
+
+	public interface SOAPVersion {
+		int v1_1 = 1;
+
+		int v1_2 = 2;
+	}
+
+	public interface QOS {
+
+		public interface DeliveryAssurance {
+
+			String IN_ORDER = "InOrder";
+
+			String NOT_IN_ORDER = "NotInOrder";
+
+			String DEFAULT_DELIVERY_ASSURANCE = IN_ORDER;
+		}
+
+		public interface InvocationType {
+
+			//invocation types
+			String EXACTLY_ONCE = "ExactlyOnce";
+
+			String MORE_THAN_ONCE = "MoreThanOnce";
+
+			String DEFAULT_INVOCATION_TYPE = EXACTLY_ONCE;
+		}
+
+	}
+
+	public interface BeanMAPs {
+		String CREATE_SEQUECE = "CreateSequenceBeanMap";
+
+		String RETRANSMITTER = "RetransmitterBeanMap";
+
+		String SEQUENCE_PROPERTY = "SequencePropertyBeanMap";
+
+		String STORAGE_MAP = "StorageMapBeanMap";
+
+		String NEXT_MESSAGE = "NextMsgBeanMap";
+	}
+
+	public interface SOAPFaults {
+
+		public interface Subcodes {
+
+			String SEQUENCE_TERMINATED = "wsrm:SequenceTerminated";
+
+			String UNKNOWN_SEQUENCE = "wsrm:UnknownSequence";
+
+			String INVALID_ACKNOWLEDGEMENT = "wsrm:InvalidAcknowledgement";
+
+			String MESSAGE_NUMBER_ROLEOVER = "wsrm:MessageNumberRollover";
+
+			String LAST_MESSAGE_NO_EXCEEDED = "wsrm:LastMessageNumberExceeded";
+
+			String CREATE_SEQUENCE_REFUSED = "wsrm:CreateSequenceRefused";
+
+		}
+
+		public interface FaultType {
+
+			public static final int UNKNOWN_SEQUENCE = 1;
+
+			public static final int MESSAGE_NUMBER_ROLLOVER = 2;
+
+			public static final int INVALID_ACKNOWLEDGEMENT = 3;
+
+			public static final int CREATE_SEQUENCE_REFUSED = 4;
+
+		}
+	}
+
+	public interface Properties {
+		
+		String RetransmissionInterval = "RetransmissionInterval";
+		
+		String AcknowledgementInterval = "AcknowledgementInterval";
+		
+		String ExponentialBackoff = "ExponentialBackoff";
+		
+		String InactivityTimeout = "InactivityTimeout";
+		
+		String InactivityTimeoutMeasure = "InactivityTimeoutMeasure";
+		
+		String StorageManager = "StorageManager";
+		
+		String InOrderInvocation = "InvokeInOrder";
+		
+		public interface DefaultValues {
+			
+			int RetransmissionInterval = 20000;
+			
+			int AcknowledgementInterval = 4000;
+			
+			boolean ExponentialBackoff = true;
+			
+			int InactivityTimeout = -1;
+			
+			String InactivityTimeoutMeasure = "seconds";   //this can be - seconds,minutes,hours,days
+			
+			String StorageManager = "org.apache.sandesha2.storage.inmemory.InMemoryStorageManager";
+		
+			boolean InvokeInOrder = true;
+		}
+	}
+	
+	public interface ClientAPI {
+		String SEQUENCE_KEY = "Sandesha2ClientAPIPropertySequenceKey";
+		String SANDESHA_DEBUG_MODE = "Sandesha2ClientAPIPropertyDebugMode";
+		String OFFERED_SEQUENCE_ID = "Sandesha2ClientAPIPropertyOfferedSequenceId";
+		String LAST_MESSAGE = "Sandesha2ClientAPIPropertyWSRMLastMessage";
+		String AcksTo = "Sandesha2ClientAPIPropertyAcksTo";
+	}
+	
+	String IN_HANDLER_NAME = "SandeshaInHandler";
+
+	String OUT_HANDLER_NAME = "SandeshaOutHandler";
+
+	String GLOBAL_IN_HANDLER_NAME = "GlobalInHandler";
+
+	String APPLICATION_PROCESSING_DONE = "AppProcessingDone";
+
+	String ACK_WRITTEN = "AckWritten";
+
+	int INVOKER_SLEEP_TIME = 1000;
+
+	int SENDER_SLEEP_TIME = 1000;
+
+	int CLIENT_SLEEP_TIME = 10000;
+
+	int TERMINATE_DELAY = 1000;
+
+	String TEMP_SEQUENCE_ID = "uuid:tempID";
+
+	String ACK_PROCSSED = "AckProcessed";
+
+	String RM_ENABLE_KEY = "RMEnabled";
+
+	String STORAGE_MANAGER_IMPL = "org.apache.sandesha2.storage.inmemory.InMemoryStorageManager";
+
+	int MAXIMUM_RETRANSMISSION_ATTEMPTS = 5;
+	
+	String PROPERTY_FILE = "sandesha2.properties";
+
+}
\ No newline at end of file

Modified: webservices/sandesha/trunk/src/org/apache/sandesha2/TerminateManager.java
URL: http://svn.apache.org/viewcvs/webservices/sandesha/trunk/src/org/apache/sandesha2/TerminateManager.java?rev=349889&r1=349888&r2=349889&view=diff
==============================================================================
--- webservices/sandesha/trunk/src/org/apache/sandesha2/TerminateManager.java (original)
+++ webservices/sandesha/trunk/src/org/apache/sandesha2/TerminateManager.java Tue Nov 29 22:03:23 2005
@@ -98,17 +98,17 @@
 			storageMapBeanMgr.delete(storageMapBean.getKey());
 		}
 		
-		SequencePropertyBean allSequenceBean = sequencePropertyBeanMgr.retrieve(Constants.SequenceProperties.ALL_SEQUENCES,Constants.SequenceProperties.INCOMING_SEQUENCE_LIST);
+		SequencePropertyBean allSequenceBean = sequencePropertyBeanMgr.retrieve(Sandesha2Constants.SequenceProperties.ALL_SEQUENCES,Sandesha2Constants.SequenceProperties.INCOMING_SEQUENCE_LIST);
 		ArrayList allSequenceList = (ArrayList) allSequenceBean.getValue();
 		
 		allSequenceList.remove(sequenceID);
 	}
 	
 	private static boolean isRequiredForResponseSide (String name) {
-		if (name==null && name.equals(Constants.SequenceProperties.LAST_OUT_MESSAGE))
+		if (name==null && name.equals(Sandesha2Constants.SequenceProperties.LAST_OUT_MESSAGE))
 			return false;
 		
-		if (name.equals(Constants.SequenceProperties.LAST_OUT_MESSAGE))
+		if (name.equals(Sandesha2Constants.SequenceProperties.LAST_OUT_MESSAGE))
 			return false;
 		
 		return false;
@@ -129,7 +129,7 @@
 		SenderBeanMgr retransmitterBeanMgr = storageManager.getRetransmitterBeanMgr();
 		CreateSeqBeanMgr createSeqBeanMgr = storageManager.getCreateSeqBeanMgr();
 		
-		SequencePropertyBean internalSequenceBean = sequencePropertyBeanMgr.retrieve(sequenceID,Constants.SequenceProperties.INTERNAL_SEQUENCE_ID);
+		SequencePropertyBean internalSequenceBean = sequencePropertyBeanMgr.retrieve(sequenceID,Sandesha2Constants.SequenceProperties.INTERNAL_SEQUENCE_ID);
 		if (internalSequenceBean==null)
 			throw new SandeshaException ("TempSequence entry not found");
 		

Modified: webservices/sandesha/trunk/src/org/apache/sandesha2/handlers/SandeshaGlobalInHandler.java
URL: http://svn.apache.org/viewcvs/webservices/sandesha/trunk/src/org/apache/sandesha2/handlers/SandeshaGlobalInHandler.java?rev=349889&r1=349888&r2=349889&view=diff
==============================================================================
--- webservices/sandesha/trunk/src/org/apache/sandesha2/handlers/SandeshaGlobalInHandler.java (original)
+++ webservices/sandesha/trunk/src/org/apache/sandesha2/handlers/SandeshaGlobalInHandler.java Tue Nov 29 22:03:23 2005
@@ -31,9 +31,10 @@
 import org.apache.axis2.soap.SOAPBody;
 import org.apache.commons.logging.Log;
 import org.apache.commons.logging.LogFactory;
-import org.apache.sandesha2.Constants;
+import org.apache.sandesha2.Sandesha2Constants;
 import org.apache.sandesha2.RMMsgContext;
 import org.apache.sandesha2.SandeshaException;
+import org.apache.sandesha2.Sandesha2Constants.ClientAPI;
 import org.apache.sandesha2.msgprocessors.ApplicationMsgProcessor;
 import org.apache.sandesha2.storage.StorageManager;
 import org.apache.sandesha2.storage.beanmanagers.SequencePropertyBeanMgr;
@@ -83,7 +84,7 @@
 		ServiceContext serviceContext = msgContext.getServiceContext();
 		Object debug = null;
 		if (serviceContext != null) {
-			debug = serviceContext.getProperty(Constants.SANDESHA_DEBUG_MODE);
+			debug = serviceContext.getProperty(ClientAPI.SANDESHA_DEBUG_MODE);
 			if (debug != null && "on".equals(debug)) {
 				System.out.println("DEBUG: SandeshaGlobalInHandler got a '"
 						+ SandeshaUtil.getMessageTypeString(rmMessageContext
@@ -116,10 +117,10 @@
 
 		boolean drop = false;
 
-		if (rmMsgContext.getMessageType() == Constants.MessageTypes.APPLICATION) {
+		if (rmMsgContext.getMessageType() == Sandesha2Constants.MessageTypes.APPLICATION) {
 
 			Sequence sequence = (Sequence) rmMsgContext
-					.getMessagePart(Constants.MessageParts.SEQUENCE);
+					.getMessagePart(Sandesha2Constants.MessageParts.SEQUENCE);
 			String sequenceId = null;
 
 			if (sequence != null) {
@@ -136,7 +137,7 @@
 						.getSequencePropretyBeanMgr();
 				SequencePropertyBean receivedMsgsBean = seqPropMgr.retrieve(
 						sequenceId,
-						Constants.SequenceProperties.RECEIVED_MESSAGES);
+						Sandesha2Constants.SequenceProperties.RECEIVED_MESSAGES);
 				if (receivedMsgsBean != null) {
 					String receivedMsgStr = (String) receivedMsgsBean
 							.getValue();
@@ -172,7 +173,7 @@
 							if (receivedMsgsBean == null) {
 								receivedMsgsBean = new SequencePropertyBean(
 										sequenceId,
-										Constants.SequenceProperties.RECEIVED_MESSAGES,
+										Sandesha2Constants.SequenceProperties.RECEIVED_MESSAGES,
 										"");
 								seqPropMgr.insert(receivedMsgsBean);
 							}
@@ -208,9 +209,9 @@
 
 	private void processDroppedMessage(RMMsgContext rmMsgContext)
 			throws SandeshaException {
-		if (rmMsgContext.getMessageType() == Constants.MessageTypes.APPLICATION) {
+		if (rmMsgContext.getMessageType() == Sandesha2Constants.MessageTypes.APPLICATION) {
 			Sequence sequence = (Sequence) rmMsgContext
-					.getMessagePart(Constants.MessageParts.SEQUENCE);
+					.getMessagePart(Sandesha2Constants.MessageParts.SEQUENCE);
 			String sequenceId = null;
 
 			if (sequence != null) {
@@ -223,7 +224,7 @@
 			SequencePropertyBeanMgr seqPropMgr = storageManager
 					.getSequencePropretyBeanMgr();
 			SequencePropertyBean receivedMsgsBean = seqPropMgr.retrieve(
-					sequenceId, Constants.SequenceProperties.RECEIVED_MESSAGES);
+					sequenceId, Sandesha2Constants.SequenceProperties.RECEIVED_MESSAGES);
 			String receivedMsgStr = (String) receivedMsgsBean.getValue();
 
 			ApplicationMsgProcessor ackProcessor = new ApplicationMsgProcessor();
@@ -237,7 +238,7 @@
 	private void doGlobalProcessing(RMMsgContext rmMsgCtx)
 			throws SandeshaException {
 		switch (rmMsgCtx.getMessageType()) {
-		case Constants.MessageTypes.ACK:
+		case Sandesha2Constants.MessageTypes.ACK:
 			rmMsgCtx.setRelatesTo(null); //Removing the relatesTo part from
 		// ackMessageIf present.
 		//Some Frameworks tend to send this.
@@ -245,6 +246,6 @@
 	}
 
 	public QName getName() {
-		return new QName(Constants.GLOBAL_IN_HANDLER_NAME);
+		return new QName(Sandesha2Constants.GLOBAL_IN_HANDLER_NAME);
 	}
 }

Modified: webservices/sandesha/trunk/src/org/apache/sandesha2/handlers/SandeshaInHandler.java
URL: http://svn.apache.org/viewcvs/webservices/sandesha/trunk/src/org/apache/sandesha2/handlers/SandeshaInHandler.java?rev=349889&r1=349888&r2=349889&view=diff
==============================================================================
--- webservices/sandesha/trunk/src/org/apache/sandesha2/handlers/SandeshaInHandler.java (original)
+++ webservices/sandesha/trunk/src/org/apache/sandesha2/handlers/SandeshaInHandler.java Tue Nov 29 22:03:23 2005
@@ -28,9 +28,10 @@
 import org.apache.axis2.handlers.AbstractHandler;
 import org.apache.commons.logging.Log;
 import org.apache.commons.logging.LogFactory;
-import org.apache.sandesha2.Constants;
+import org.apache.sandesha2.Sandesha2Constants;
 import org.apache.sandesha2.SandeshaException;
 import org.apache.sandesha2.RMMsgContext;
+import org.apache.sandesha2.Sandesha2Constants.ClientAPI;
 import org.apache.sandesha2.msgprocessors.MsgProcessor;
 import org.apache.sandesha2.msgprocessors.MsgProcessorFactory;
 import org.apache.sandesha2.util.FaultManager;
@@ -49,7 +50,7 @@
 	protected Log log = LogFactory.getLog(SandeshaInHandler.class.getName());
 
 	public QName getName() {
-		return new QName(Constants.IN_HANDLER_NAME);
+		return new QName(Sandesha2Constants.IN_HANDLER_NAME);
 	}
 
 	public void invoke(MessageContext msgCtx) throws AxisFault {
@@ -59,7 +60,7 @@
 			throw new AxisFault("ConfigurationContext is null");
 
 		String DONE = (String) msgCtx
-				.getProperty(Constants.APPLICATION_PROCESSING_DONE);
+				.getProperty(Sandesha2Constants.APPLICATION_PROCESSING_DONE);
 		if (null != DONE && "true".equals(DONE))
 			return;
 
@@ -86,7 +87,7 @@
 		ServiceContext serviceContext = msgCtx.getServiceContext();
 		Object debug = null;
 		if (serviceContext != null) {
-			debug = serviceContext.getProperty(Constants.SANDESHA_DEBUG_MODE);
+			debug = serviceContext.getProperty(ClientAPI.SANDESHA_DEBUG_MODE);
 			if (debug != null && "on".equals(debug)) {
 				System.out.println("DEBUG: SandeshaInHandler got a '"
 						+ SandeshaUtil.getMessageTypeString(rmMsgCtx

Modified: webservices/sandesha/trunk/src/org/apache/sandesha2/handlers/SandeshaOutHandler.java
URL: http://svn.apache.org/viewcvs/webservices/sandesha/trunk/src/org/apache/sandesha2/handlers/SandeshaOutHandler.java?rev=349889&r1=349888&r2=349889&view=diff
==============================================================================
--- webservices/sandesha/trunk/src/org/apache/sandesha2/handlers/SandeshaOutHandler.java (original)
+++ webservices/sandesha/trunk/src/org/apache/sandesha2/handlers/SandeshaOutHandler.java Tue Nov 29 22:03:23 2005
@@ -37,9 +37,10 @@
 import org.apache.axis2.soap.SOAPFactory;
 import org.apache.commons.logging.Log;
 import org.apache.commons.logging.LogFactory;
-import org.apache.sandesha2.Constants;
+import org.apache.sandesha2.Sandesha2Constants;
 import org.apache.sandesha2.RMMsgContext;
 import org.apache.sandesha2.SandeshaException;
+import org.apache.sandesha2.Sandesha2Constants.ClientAPI;
 import org.apache.sandesha2.policy.RMPolicyBean;
 import org.apache.sandesha2.storage.StorageManager;
 import org.apache.sandesha2.storage.beanmanagers.CreateSeqBeanMgr;
@@ -87,16 +88,16 @@
 		RMMsgContext rmMsgCtx = MsgInitializer.initializeMessage(msgCtx);
 
 		String DONE = (String) msgCtx
-				.getProperty(Constants.APPLICATION_PROCESSING_DONE);
+				.getProperty(Sandesha2Constants.APPLICATION_PROCESSING_DONE);
 		if (null != DONE && "true".equals(DONE))
 			return;
 
-		msgCtx.setProperty(Constants.APPLICATION_PROCESSING_DONE, "true");
+		msgCtx.setProperty(Sandesha2Constants.APPLICATION_PROCESSING_DONE, "true");
 
 		ServiceContext serviceContext = msgCtx.getServiceContext();
 		Object debug = null;
 		if (serviceContext != null) {
-			debug = serviceContext.getProperty(Constants.SANDESHA_DEBUG_MODE);
+			debug = serviceContext.getProperty(ClientAPI.SANDESHA_DEBUG_MODE);
 			if (debug != null && "on".equals(debug)) {
 				System.out.println("DEBUG: SandeshaOutHandler got a '"
 						+ SandeshaUtil.getMessageTypeString(rmMsgCtx
@@ -105,7 +106,7 @@
 		}
 
 		//continue only if an possible application message
-		if (!(rmMsgCtx.getMessageType() == Constants.MessageTypes.UNKNOWN)) {
+		if (!(rmMsgCtx.getMessageType() == Sandesha2Constants.MessageTypes.UNKNOWN)) {
 			return;
 		}
 
@@ -114,7 +115,7 @@
 
 		//Adding the policy bean
 		RMPolicyBean policyBean = RMPolicyManager.getPolicyBean(rmMsgCtx);
-		rmMsgCtx.setProperty(Constants.WSP.RM_POLICY_BEAN, policyBean);
+		rmMsgCtx.setProperty(Sandesha2Constants.WSP.RM_POLICY_BEAN, policyBean);
 
 		StorageManager storageManager = SandeshaUtil
 				.getSandeshaStorageManager(context);
@@ -147,7 +148,7 @@
 					.initializeMessage(reqMsgCtx);
 
 			Sequence reqSequence = (Sequence) requestRMMsgCtx
-					.getMessagePart(Constants.MessageParts.SEQUENCE);
+					.getMessagePart(Sandesha2Constants.MessageParts.SEQUENCE);
 			if (reqSequence == null)
 				throw new SandeshaException("Sequence part is null");
 
@@ -167,7 +168,7 @@
 
 			internalSequenceId = toEPR.getAddress();
 			String sequenceKey = (String) context
-					.getProperty(Constants.SEQUENCE_KEY);
+					.getProperty(ClientAPI.SEQUENCE_KEY);
 			if (sequenceKey != null)
 				internalSequenceId = internalSequenceId + sequenceKey;
 
@@ -181,7 +182,7 @@
 
 		SequencePropertyBean outSeqBean = seqPropMgr.retrieve(
 				internalSequenceId,
-				Constants.SequenceProperties.OUT_SEQUENCE_ID);
+				Sandesha2Constants.SequenceProperties.OUT_SEQUENCE_ID);
 
 		if (messageNumber == 1) {
 			if (outSeqBean == null) {
@@ -199,26 +200,26 @@
 
 			SequencePropertyBean responseCreateSeqAdded = seqPropMgr.retrieve(
 					internalSequenceId,
-					Constants.SequenceProperties.OUT_CREATE_SEQUENCE_SENT);
+					Sandesha2Constants.SequenceProperties.OUT_CREATE_SEQUENCE_SENT);
 
 			if (responseCreateSeqAdded == null) {
 				responseCreateSeqAdded = new SequencePropertyBean(
 						internalSequenceId,
-						Constants.SequenceProperties.OUT_CREATE_SEQUENCE_SENT,
+						Sandesha2Constants.SequenceProperties.OUT_CREATE_SEQUENCE_SENT,
 						"true");
 				seqPropMgr.insert(responseCreateSeqAdded);
 
 				String acksTo = null;
 				if (serviceContext != null) {
 					acksTo = (String) serviceContext
-							.getProperty(Constants.AcksTo);
+							.getProperty(ClientAPI.AcksTo);
 				}
 
 				if (acksTo == null)
-					acksTo = Constants.WSA.NS_URI_ANONYMOUS;
+					acksTo = Sandesha2Constants.WSA.NS_URI_ANONYMOUS;
 
 				//If acksTo is not anonymous. Start the listner TODO: verify
-				if (!Constants.WSA.NS_URI_ANONYMOUS.equals(acksTo)
+				if (!Sandesha2Constants.WSA.NS_URI_ANONYMOUS.equals(acksTo)
 						&& !serverSide) {
 					String transportIn = (String) context
 							.getProperty(MessageContext.TRANSPORT_IN);
@@ -230,14 +231,14 @@
 							.getServerSideIncomingSeqIdFromInternalSeqId(internalSequenceId);
 					SequencePropertyBean bean = seqPropMgr.retrieve(
 							incomingSequencId,
-							Constants.SequenceProperties.REPLY_TO_EPR);
+							Sandesha2Constants.SequenceProperties.REPLY_TO_EPR);
 					if (bean != null) {
 						EndpointReference acksToEPR = (EndpointReference) bean
 								.getValue();
 						if (acksToEPR != null)
 							acksTo = (String) acksToEPR.getAddress();
 					}
-				} else if (Constants.WSA.NS_URI_ANONYMOUS.equals(acksTo)) {
+				} else if (Sandesha2Constants.WSA.NS_URI_ANONYMOUS.equals(acksTo)) {
 					//set transport in.
 					Object trIn = msgCtx
 							.getProperty(MessageContext.TRANSPORT_IN);
@@ -282,9 +283,9 @@
 
 			//let the request end with 202 if a ack has not been
 			// written in the incoming thread.
-			if (reqMsgCtx.getProperty(Constants.ACK_WRITTEN) == null
+			if (reqMsgCtx.getProperty(Sandesha2Constants.ACK_WRITTEN) == null
 					|| !"true".equals(reqMsgCtx
-							.getProperty(Constants.ACK_WRITTEN)))
+							.getProperty(Sandesha2Constants.ACK_WRITTEN)))
 				reqMsgCtx.getOperationContext().setProperty(
 						org.apache.axis2.Constants.RESPONSE_WRITTEN, "false");
 		} else {
@@ -323,7 +324,7 @@
 		RMMsgContext createSeqRMMessage = RMMsgCreator.createCreateSeqMsg(
 				applicationRMMsg, internalSequenceId, acksTo);
 		CreateSequence createSequencePart = (CreateSequence) createSeqRMMessage
-				.getMessagePart(Constants.MessageParts.CREATE_SEQ);
+				.getMessagePart(Sandesha2Constants.MessageParts.CREATE_SEQ);
 		if (createSequencePart == null)
 			throw new SandeshaException(
 					"Create Sequence part is null for a CreateSequence message");
@@ -334,12 +335,12 @@
 			String offeredSequenceId = offer.getIdentifer().getIdentifier();
 			SequencePropertyBean msgsBean = new SequencePropertyBean();
 			msgsBean.setSequenceId(offeredSequenceId);
-			msgsBean.setName(Constants.SequenceProperties.RECEIVED_MESSAGES);
+			msgsBean.setName(Sandesha2Constants.SequenceProperties.RECEIVED_MESSAGES);
 			msgsBean.setValue("");
 
 			SequencePropertyBean offeredSequenceBean = new SequencePropertyBean();
 			offeredSequenceBean
-					.setName(Constants.SequenceProperties.OFFERED_SEQUENCE);
+					.setName(Sandesha2Constants.SequenceProperties.OFFERED_SEQUENCE);
 			offeredSequenceBean.setSequenceId(internalSequenceId);
 			offeredSequenceBean.setValue(offeredSequenceId);
 
@@ -371,7 +372,7 @@
 
 		if (createSeqMsg.getReplyTo() == null)
 			createSeqMsg.setReplyTo(new EndpointReference(
-					Constants.WSA.NS_URI_ANONYMOUS));
+					Sandesha2Constants.WSA.NS_URI_ANONYMOUS));
 
 		SenderBeanMgr retransmitterMgr = storageManager
 				.getRetransmitterBeanMgr();
@@ -411,14 +412,14 @@
 				.getRetransmitterBeanMgr();
 
 		SequencePropertyBean toBean = sequencePropertyMgr.retrieve(
-				internalSequenceId, Constants.SequenceProperties.TO_EPR);
+				internalSequenceId, Sandesha2Constants.SequenceProperties.TO_EPR);
 		SequencePropertyBean replyToBean = sequencePropertyMgr.retrieve(
-				internalSequenceId, Constants.SequenceProperties.REPLY_TO_EPR);
+				internalSequenceId, Sandesha2Constants.SequenceProperties.REPLY_TO_EPR);
 
 		//again - looks weird in the client side - but consistent
 		SequencePropertyBean outSequenceBean = sequencePropertyMgr.retrieve(
 				internalSequenceId,
-				Constants.SequenceProperties.OUT_SEQUENCE_ID);
+				Sandesha2Constants.SequenceProperties.OUT_SEQUENCE_ID);
 
 		if (toBean == null)
 			throw new SandeshaException("To is null");
@@ -480,7 +481,7 @@
 			RMMsgContext reqRMMsgCtx = MsgInitializer
 					.initializeMessage(requestMsg);
 			Sequence requestSequence = (Sequence) reqRMMsgCtx
-					.getMessagePart(Constants.MessageParts.SEQUENCE);
+					.getMessagePart(Sandesha2Constants.MessageParts.SEQUENCE);
 			if (requestSequence == null)
 				throw new SandeshaException("Request Sequence is null");
 
@@ -491,7 +492,7 @@
 				//saving the last message no.
 				SequencePropertyBean lastOutMsgBean = new SequencePropertyBean(
 						internalSequenceId,
-						Constants.SequenceProperties.LAST_OUT_MESSAGE,
+						Sandesha2Constants.SequenceProperties.LAST_OUT_MESSAGE,
 						new Long(messageNumber));
 				sequencePropertyMgr.insert(lastOutMsgBean);
 			}
@@ -501,14 +502,14 @@
 
 			ServiceContext serviceContext = msg.getServiceContext();
 			if (serviceContext != null) {
-				Object obj = serviceContext.getProperty(Constants.LAST_MESSAGE);
+				Object obj = serviceContext.getProperty(ClientAPI.LAST_MESSAGE);
 				if (obj != null && "true".equals(obj)) {
 					lastMessage = true;
 					sequence.setLastMessage(new LastMessage(factory));
 					//saving the last message no.
 					SequencePropertyBean lastOutMsgBean = new SequencePropertyBean(
 							internalSequenceId,
-							Constants.SequenceProperties.LAST_OUT_MESSAGE,
+							Sandesha2Constants.SequenceProperties.LAST_OUT_MESSAGE,
 							new Long(messageNumber));
 					sequencePropertyMgr.insert(lastOutMsgBean);
 				}
@@ -526,7 +527,7 @@
 		// sequence id.
 		String identifierStr = null;
 		if (outSequenceBean == null || outSequenceBean.getValue() == null) {
-			identifierStr = Constants.TEMP_SEQUENCE_ID;
+			identifierStr = Sandesha2Constants.TEMP_SEQUENCE_ID;
 
 		} else {
 			identifierStr = (String) outSequenceBean.getValue();
@@ -535,14 +536,14 @@
 		Identifier id1 = new Identifier(factory);
 		id1.setIndentifer(identifierStr);
 		sequence.setIdentifier(id1);
-		rmMsg.setMessagePart(Constants.MessageParts.SEQUENCE, sequence);
+		rmMsg.setMessagePart(Sandesha2Constants.MessageParts.SEQUENCE, sequence);
 
 		if (addAckRequested) {
 			ackRequested = new AckRequested(factory);
 			Identifier id2 = new Identifier(factory);
 			id2.setIndentifer(identifierStr);
 			ackRequested.setIdentifier(id2);
-			rmMsg.setMessagePart(Constants.MessageParts.ACK_REQUEST,
+			rmMsg.setMessagePart(Sandesha2Constants.MessageParts.ACK_REQUEST,
 					ackRequested);
 		}
 
@@ -580,7 +581,7 @@
 				.getSequencePropretyBeanMgr();
 		SequencePropertyBean nextMsgNoBean = seqPropMgr.retrieve(
 				internalSequenceId,
-				Constants.SequenceProperties.NEXT_MESSAGE_NUMBER);
+				Sandesha2Constants.SequenceProperties.NEXT_MESSAGE_NUMBER);
 		long nextMsgNo = 1;
 		boolean update = false;
 		if (nextMsgNoBean != null) {
@@ -591,7 +592,7 @@
 			nextMsgNoBean = new SequencePropertyBean();
 			nextMsgNoBean.setSequenceId(internalSequenceId);
 			nextMsgNoBean
-					.setName(Constants.SequenceProperties.NEXT_MESSAGE_NUMBER);
+					.setName(Sandesha2Constants.SequenceProperties.NEXT_MESSAGE_NUMBER);
 		}
 
 		nextMsgNoBean.setValue(new Long(nextMsgNo + 1));
@@ -604,6 +605,6 @@
 	}
 
 	public QName getName() {
-		return new QName(Constants.OUT_HANDLER_NAME);
+		return new QName(Sandesha2Constants.OUT_HANDLER_NAME);
 	}
 }

Modified: webservices/sandesha/trunk/src/org/apache/sandesha2/msgprocessors/AcknowledgementProcessor.java
URL: http://svn.apache.org/viewcvs/webservices/sandesha/trunk/src/org/apache/sandesha2/msgprocessors/AcknowledgementProcessor.java?rev=349889&r1=349888&r2=349889&view=diff
==============================================================================
--- webservices/sandesha/trunk/src/org/apache/sandesha2/msgprocessors/AcknowledgementProcessor.java (original)
+++ webservices/sandesha/trunk/src/org/apache/sandesha2/msgprocessors/AcknowledgementProcessor.java Tue Nov 29 22:03:23 2005
@@ -23,7 +23,7 @@
 import org.apache.axis2.AxisFault;
 import org.apache.axis2.addressing.EndpointReference;
 import org.apache.axis2.context.AbstractContext;
-import org.apache.sandesha2.Constants;
+import org.apache.sandesha2.Sandesha2Constants;
 import org.apache.sandesha2.RMMsgContext;
 import org.apache.sandesha2.SandeshaException;
 import org.apache.sandesha2.storage.StorageManager;
@@ -48,7 +48,7 @@
 	public void processMessage(RMMsgContext rmMsgCtx) throws SandeshaException {
 
 		SequenceAcknowledgement sequenceAck = (SequenceAcknowledgement) rmMsgCtx
-				.getMessagePart(Constants.MessageParts.SEQ_ACKNOWLEDGEMENT);
+				.getMessagePart(Sandesha2Constants.MessageParts.SEQ_ACKNOWLEDGEMENT);
 		if (sequenceAck == null)
 			throw new SandeshaException("Sequence acknowledgement part is null");
 
@@ -73,7 +73,7 @@
 			throw new SandeshaException("OutSequenceId is null");
 
 		SequencePropertyBean internalSequenceBean = seqPropMgr.retrieve(
-				outSequenceId, Constants.SequenceProperties.INTERNAL_SEQUENCE_ID);
+				outSequenceId, Sandesha2Constants.SequenceProperties.INTERNAL_SEQUENCE_ID);
 
 		if (internalSequenceBean == null || internalSequenceBean.getValue() == null)
 			throw new SandeshaException("TempSequenceId is not set correctly");
@@ -82,7 +82,7 @@
 
 		//Following happens in the SandeshaGlobal handler
 		rmMsgCtx.getMessageContext()
-				.setProperty(Constants.ACK_PROCSSED, "true");
+				.setProperty(Sandesha2Constants.ACK_PROCSSED, "true");
 
 		//Removing relatesTo - Some WSRM endpoints tend to set relatesTo value
 		// for ack messages.
@@ -90,7 +90,7 @@
 		//So we set relatesTo value to null for ackMessages. (this happens in
 		// the SandeshaGlobal handler)
 		//Do this only if this is a standalone ACK.
-		if (rmMsgCtx.getMessageType() == Constants.MessageTypes.ACK)
+		if (rmMsgCtx.getMessageType() == Sandesha2Constants.MessageTypes.ACK)
 			rmMsgCtx.setRelatesTo(null);
 
 		SenderBean input = new SenderBean();
@@ -124,7 +124,7 @@
 		//If all messages up to last message have been acknowledged.
 		//Add terminate Sequence message.
 		SequencePropertyBean lastOutMsgBean = seqPropMgr.retrieve(
-				internalSequenceId, Constants.SequenceProperties.LAST_OUT_MESSAGE);
+				internalSequenceId, Sandesha2Constants.SequenceProperties.LAST_OUT_MESSAGE);
 		if (lastOutMsgBean != null) {
 			Long lastOutMsgNoLng = (Long) lastOutMsgBean.getValue();
 			if (lastOutMsgNoLng == null)
@@ -147,7 +147,7 @@
 
 			//stopping the progress of the message further.
 			rmMsgCtx.getMessageContext().setPausedTrue(
-					new QName(Constants.IN_HANDLER_NAME));
+					new QName(Sandesha2Constants.IN_HANDLER_NAME));
 		}
 	}
 
@@ -175,7 +175,7 @@
 				.getSequencePropretyBeanMgr();
 
 		SequencePropertyBean terminated = seqPropMgr.retrieve(outSequenceId,
-				Constants.SequenceProperties.TERMINATE_ADDED);
+				Sandesha2Constants.SequenceProperties.TERMINATE_ADDED);
 
 		if (terminated != null && terminated.getValue() != null
 				&& "true".equals(terminated.getValue())) {
@@ -187,7 +187,7 @@
 				.createTerminateSequenceMessage(incomingAckRMMsg, outSequenceId);
 
 		SequencePropertyBean toBean = seqPropMgr.retrieve(internalSequenceId,
-				Constants.SequenceProperties.TO_EPR);
+				Sandesha2Constants.SequenceProperties.TO_EPR);
 
 		EndpointReference toEPR = (EndpointReference) toBean.getValue();
 		if (toEPR == null)
@@ -195,13 +195,13 @@
 
 		terminateRMMessage.setTo(new EndpointReference(toEPR.getAddress()));
 		terminateRMMessage.setFrom(new EndpointReference(
-				Constants.WSA.NS_URI_ANONYMOUS));
+				Sandesha2Constants.WSA.NS_URI_ANONYMOUS));
 		terminateRMMessage.setFaultTo(new EndpointReference(
-				Constants.WSA.NS_URI_ANONYMOUS));
+				Sandesha2Constants.WSA.NS_URI_ANONYMOUS));
 		terminateRMMessage
-				.setWSAAction(Constants.WSRM.Actions.ACTION_TERMINATE_SEQUENCE);
+				.setWSAAction(Sandesha2Constants.WSRM.Actions.ACTION_TERMINATE_SEQUENCE);
 		terminateRMMessage
-				.setSOAPAction(Constants.WSRM.Actions.SOAP_ACTION_TERMINATE_SEQUENCE);
+				.setSOAPAction(Sandesha2Constants.WSRM.Actions.SOAP_ACTION_TERMINATE_SEQUENCE);
 
 		try {
 			terminateRMMessage.addSOAPEnvelope();
@@ -218,7 +218,7 @@
 		// some delay.
 		//Otherwise this get send before return of the current request (ack).
 		terminateBean.setTimeToSend(System.currentTimeMillis()
-				+ Constants.TERMINATE_DELAY);
+				+ Sandesha2Constants.TERMINATE_DELAY);
 
 		terminateBean.setMessageId(terminateRMMessage.getMessageId());
 		terminateBean.setSend(true);
@@ -228,7 +228,7 @@
 				.getRetransmitterBeanMgr();
 
 		SequencePropertyBean terminateAdded = new SequencePropertyBean();
-		terminateAdded.setName(Constants.SequenceProperties.TERMINATE_ADDED);
+		terminateAdded.setName(Sandesha2Constants.SequenceProperties.TERMINATE_ADDED);
 		terminateAdded.setSequenceId(outSequenceId);
 		terminateAdded.setValue("true");
 

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=349889&r1=349888&r2=349889&view=diff
==============================================================================
--- webservices/sandesha/trunk/src/org/apache/sandesha2/msgprocessors/ApplicationMsgProcessor.java (original)
+++ webservices/sandesha/trunk/src/org/apache/sandesha2/msgprocessors/ApplicationMsgProcessor.java Tue Nov 29 22:03:23 2005
@@ -38,7 +38,7 @@
 import org.apache.axis2.engine.AxisEngine;
 import org.apache.axis2.soap.SOAPEnvelope;
 import org.apache.axis2.soap.SOAPFactory;
-import org.apache.sandesha2.Constants;
+import org.apache.sandesha2.Sandesha2Constants;
 import org.apache.sandesha2.RMMsgContext;
 import org.apache.sandesha2.SandeshaException;
 import org.apache.sandesha2.policy.RMPolicyBean;
@@ -76,7 +76,7 @@
 
 		//Processing for ack if any
 		SequenceAcknowledgement sequenceAck = (SequenceAcknowledgement) rmMsgCtx
-				.getMessagePart(Constants.MessageParts.SEQ_ACKNOWLEDGEMENT);
+				.getMessagePart(Sandesha2Constants.MessageParts.SEQ_ACKNOWLEDGEMENT);
 		if (sequenceAck != null) {
 			AcknowledgementProcessor ackProcessor = new AcknowledgementProcessor();
 			ackProcessor.processMessage(rmMsgCtx);
@@ -87,8 +87,8 @@
 		if (msgCtx == null)
 			throw new SandeshaException("Message context is null");
 
-		if (rmMsgCtx.getProperty(Constants.APPLICATION_PROCESSING_DONE) != null
-				&& rmMsgCtx.getProperty(Constants.APPLICATION_PROCESSING_DONE)
+		if (rmMsgCtx.getProperty(Sandesha2Constants.APPLICATION_PROCESSING_DONE) != null
+				&& rmMsgCtx.getProperty(Sandesha2Constants.APPLICATION_PROCESSING_DONE)
 						.equals("true")) {
 			return;
 		}
@@ -101,7 +101,7 @@
 
 		//setting acked msg no range
 		Sequence sequence = (Sequence) rmMsgCtx
-				.getMessagePart(Constants.MessageParts.SEQUENCE);
+				.getMessagePart(Sandesha2Constants.MessageParts.SEQUENCE);
 		String sequenceId = sequence.getIdentifier().getIdentifier();
 		ConfigurationContext configCtx = rmMsgCtx.getMessageContext()
 				.getSystemContext();
@@ -109,7 +109,7 @@
 			throw new SandeshaException("Configuration Context is null");
 
 		SequencePropertyBean msgsBean = seqPropMgr.retrieve(sequenceId,
-				Constants.SequenceProperties.RECEIVED_MESSAGES);
+				Sandesha2Constants.SequenceProperties.RECEIVED_MESSAGES);
 
 		long msgNo = sequence.getMessageNumber().getMessageNumber();
 		if (msgNo == 0)
@@ -118,11 +118,11 @@
 		String messagesStr = (String) msgsBean.getValue();
 
 		if (msgNoPresentInList(messagesStr, msgNo)
-				&& (Constants.QOS.InvocationType.DEFAULT_INVOCATION_TYPE == Constants.QOS.InvocationType.EXACTLY_ONCE)) {
+				&& (Sandesha2Constants.QOS.InvocationType.DEFAULT_INVOCATION_TYPE == Sandesha2Constants.QOS.InvocationType.EXACTLY_ONCE)) {
 			//this is a duplicate message and the invocation type is
 			// EXACTLY_ONCE.
 
-			msgCtx.setPausedTrue(new QName(Constants.IN_HANDLER_NAME));
+			msgCtx.setPausedTrue(new QName(Sandesha2Constants.IN_HANDLER_NAME));
 
 		}
 
@@ -151,20 +151,20 @@
 			boolean inOrderInvocation = PropertyManager.getInstance().isInOrderInvocation();
 			if (inOrderInvocation) {
 				//pause the message
-				msgCtx.setPausedTrue(new QName(Constants.IN_HANDLER_NAME));
+				msgCtx.setPausedTrue(new QName(Sandesha2Constants.IN_HANDLER_NAME));
 
 				SequencePropertyBean incomingSequenceListBean = (SequencePropertyBean) seqPropMgr
 						.retrieve(
-								Constants.SequenceProperties.ALL_SEQUENCES,
-								Constants.SequenceProperties.INCOMING_SEQUENCE_LIST);
+								Sandesha2Constants.SequenceProperties.ALL_SEQUENCES,
+								Sandesha2Constants.SequenceProperties.INCOMING_SEQUENCE_LIST);
 
 				if (incomingSequenceListBean == null) {
 					ArrayList incomingSequenceList = new ArrayList();
 					incomingSequenceListBean = new SequencePropertyBean();
 					incomingSequenceListBean
-							.setSequenceId(Constants.SequenceProperties.ALL_SEQUENCES);
+							.setSequenceId(Sandesha2Constants.SequenceProperties.ALL_SEQUENCES);
 					incomingSequenceListBean
-							.setName(Constants.SequenceProperties.INCOMING_SEQUENCE_LIST);
+							.setName(Sandesha2Constants.SequenceProperties.INCOMING_SEQUENCE_LIST);
 					incomingSequenceListBean.setValue(incomingSequenceList);
 
 					seqPropMgr.insert(incomingSequenceListBean);
@@ -188,7 +188,7 @@
 					//This will avoid performing application processing more
 					// than
 					// once.
-					rmMsgCtx.setProperty(Constants.APPLICATION_PROCESSING_DONE,
+					rmMsgCtx.setProperty(Sandesha2Constants.APPLICATION_PROCESSING_DONE,
 							"true");
 
 				} catch (Exception ex) {
@@ -208,7 +208,7 @@
 			String requestMessageId = requestMessage.getMessageID();
 			SequencePropertyBean checkResponseBean = seqPropMgr.retrieve(
 					requestMessageId,
-					Constants.SequenceProperties.CHECK_RESPONSE);
+					Sandesha2Constants.SequenceProperties.CHECK_RESPONSE);
 			if (checkResponseBean != null) {
 				checkResponseBean.setValue(msgCtx);
 				seqPropMgr.update(checkResponseBean);
@@ -246,7 +246,7 @@
 				.getSequencePropretyBeanMgr();
 
 		Sequence sequence = (Sequence) rmMsgCtx
-				.getMessagePart(Constants.MessageParts.SEQUENCE);
+				.getMessagePart(Sandesha2Constants.MessageParts.SEQUENCE);
 		String sequenceId = sequence.getIdentifier().getIdentifier();
 		ConfigurationContext configCtx = rmMsgCtx.getMessageContext()
 				.getSystemContext();
@@ -254,12 +254,12 @@
 			throw new SandeshaException("Configuration Context is null");
 
 		AckRequested ackRequested = (AckRequested) rmMsgCtx
-				.getMessagePart(Constants.MessageParts.ACK_REQUEST);
+				.getMessagePart(Sandesha2Constants.MessageParts.ACK_REQUEST);
 		LastMessage lastMessage = (LastMessage) sequence.getLastMessage();
 
 		//Setting the ack depending on AcksTo.
 		SequencePropertyBean acksToBean = seqPropMgr.retrieve(sequenceId,
-				Constants.SequenceProperties.ACKS_TO_EPR);
+				Sandesha2Constants.SequenceProperties.ACKS_TO_EPR);
 
 		EndpointReference acksTo = (EndpointReference) acksToBean.getValue();
 		String acksToStr = acksTo.getAddress();
@@ -268,7 +268,7 @@
 			throw new SandeshaException(
 					"Seqeunce properties are not set correctly");
 
-		if (Constants.WSA.NS_URI_ANONYMOUS.equals(acksTo.getAddress())) {
+		if (Sandesha2Constants.WSA.NS_URI_ANONYMOUS.equals(acksTo.getAddress())) {
 			// send ack in the sync case, only if the last message or the
 			// ackRequested tag is present.
 			boolean ackRequired = false;
@@ -316,7 +316,7 @@
 		ackMsgCtx.setReplyTo(msgCtx.getTo());
 		RMMsgCreator.addAckMessage(ackRMMsgCtx, sequenceId);
 
-		if (Constants.WSA.NS_URI_ANONYMOUS.equals(acksTo.getAddress())) {
+		if (Sandesha2Constants.WSA.NS_URI_ANONYMOUS.equals(acksTo.getAddress())) {
 
 			AxisEngine engine = new AxisEngine(ackRMMsgCtx.getMessageContext()
 					.getSystemContext());
@@ -339,7 +339,7 @@
 			rmMsgCtx.getMessageContext().getOperationContext().setProperty(
 					org.apache.axis2.Constants.RESPONSE_WRITTEN, "true");
 
-			rmMsgCtx.getMessageContext().setProperty(Constants.ACK_WRITTEN,
+			rmMsgCtx.getMessageContext().setProperty(Sandesha2Constants.ACK_WRITTEN,
 					"true");
 			try {
 				engine.send(ackRMMsgCtx.getMessageContext());
@@ -357,7 +357,7 @@
 			ackBean.setMessageId(ackMsgCtx.getMessageID());
 			ackBean.setReSend(false);
 			ackBean.setSend(true);
-			ackBean.setMessagetype(Constants.MessageTypes.ACK);
+			ackBean.setMessagetype(Sandesha2Constants.MessageTypes.ACK);
 
 			//the internalSequenceId value of the retransmitter Table for the
 			// messages related to an incoming
@@ -365,7 +365,7 @@
 			ackBean.setInternalSequenceId(sequenceId);
 
 			RMPolicyBean policyBean = (RMPolicyBean) rmMsgCtx
-					.getProperty(Constants.WSP.RM_POLICY_BEAN);
+					.getProperty(Sandesha2Constants.WSP.RM_POLICY_BEAN);
 			long ackInterval = PropertyManager.getInstance().getAcknowledgementInterval();
 			if (policyBean != null) {
 				ackInterval = policyBean.getAcknowledgementInaterval();
@@ -378,7 +378,7 @@
 
 			//removing old acks.
 			SenderBean findBean = new SenderBean();
-			findBean.setMessagetype(Constants.MessageTypes.ACK);
+			findBean.setMessagetype(Sandesha2Constants.MessageTypes.ACK);
 			findBean.setInternalSequenceId(sequenceId);
 			Collection coll = retransmitterBeanMgr.find(findBean);
 			Iterator it = coll.iterator();

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=349889&r1=349888&r2=349889&view=diff
==============================================================================
--- webservices/sandesha/trunk/src/org/apache/sandesha2/msgprocessors/CreateSeqMsgProcessor.java (original)
+++ webservices/sandesha/trunk/src/org/apache/sandesha2/msgprocessors/CreateSeqMsgProcessor.java Tue Nov 29 22:03:23 2005
@@ -25,7 +25,7 @@
 import org.apache.axis2.context.MessageContext;
 import org.apache.axis2.engine.AxisEngine;
 import org.apache.axis2.util.Utils;
-import org.apache.sandesha2.Constants;
+import org.apache.sandesha2.Sandesha2Constants;
 import org.apache.sandesha2.RMMsgContext;
 import org.apache.sandesha2.SandeshaException;
 import org.apache.sandesha2.storage.StorageManager;
@@ -54,7 +54,7 @@
 
 		MessageContext createSeqMsg = createSeqRMMsg.getMessageContext();
 		CreateSequence createSeqPart = (CreateSequence) createSeqRMMsg
-				.getMessagePart(Constants.MessageParts.CREATE_SEQ);
+				.getMessagePart(Sandesha2Constants.MessageParts.CREATE_SEQ);
 		if (createSeqPart == null)
 			throw new SandeshaException(
 					"No create sequence part is present in the create sequence message");
@@ -79,7 +79,7 @@
 					.createCreateSeqResponseMsg(createSeqRMMsg, outMessage,
 							newSequenceId);
 			CreateSequenceResponse createSeqResPart = (CreateSequenceResponse) createSeqResponse
-					.getMessagePart(Constants.MessageParts.CREATE_SEQ_RESPONSE);
+					.getMessagePart(Sandesha2Constants.MessageParts.CREATE_SEQ_RESPONSE);
 
 			//If an offer is accepted do necessary procesing.
 			Accept accept = createSeqResPart.getAccept();
@@ -111,7 +111,7 @@
 						.getSequencePropretyBeanMgr();
 				SequencePropertyBean outSequenceBean = new SequencePropertyBean();
 				outSequenceBean
-						.setName(Constants.SequenceProperties.OUT_SEQUENCE_ID);
+						.setName(Sandesha2Constants.SequenceProperties.OUT_SEQUENCE_ID);
 				outSequenceBean.setValue(outSequenceId);
 				outSequenceBean.setSequenceId(newSequenceId);
 				seqPropMgr.insert(outSequenceBean);
@@ -120,11 +120,11 @@
 				//If internal sequence id is not set. this implies server side.
 				SequencePropertyBean internalSeqBean = seqPropMgr.retrieve(
 						outSequenceId,
-						Constants.SequenceProperties.INTERNAL_SEQUENCE_ID);
+						Sandesha2Constants.SequenceProperties.INTERNAL_SEQUENCE_ID);
 				if (internalSeqBean == null) {
 					SequencePropertyBean internalSequenceBean = new SequencePropertyBean();
 					internalSequenceBean
-							.setName(Constants.SequenceProperties.INTERNAL_SEQUENCE_ID);
+							.setName(Sandesha2Constants.SequenceProperties.INTERNAL_SEQUENCE_ID);
 					internalSequenceBean.setSequenceId(outSequenceId);
 					internalSequenceBean.setValue(newSequenceId);
 					seqPropMgr.insert(internalSequenceBean);
@@ -133,7 +133,7 @@
 			}
 
 			CreateSequence createSeq = (CreateSequence) createSeqRMMsg
-					.getMessagePart(Constants.MessageParts.CREATE_SEQ);
+					.getMessagePart(Sandesha2Constants.MessageParts.CREATE_SEQ);
 			if (createSeq == null)
 				throw new AxisFault(
 						"Create sequence part not present in the create sequence message");
@@ -146,7 +146,7 @@
 						"Acks to not present in the create sequence message");
 
 			SequencePropertyBean seqPropBean = new SequencePropertyBean(
-					newSequenceId, Constants.SequenceProperties.ACKS_TO_EPR,
+					newSequenceId, Sandesha2Constants.SequenceProperties.ACKS_TO_EPR,
 					acksTo);
 
 			StorageManager storageManager = SandeshaUtil
@@ -164,7 +164,7 @@
 
 			Object obj = createSeqMsg.getOperationContext().getProperty(
 					org.apache.axis2.Constants.RESPONSE_WRITTEN);
-			if (Constants.WSA.NS_URI_ANONYMOUS.equals(createSeqMsg.getReplyTo()
+			if (Sandesha2Constants.WSA.NS_URI_ANONYMOUS.equals(createSeqMsg.getReplyTo()
 					.getAddress())) {
 				createSeqMsg.getOperationContext().setProperty(
 						org.apache.axis2.Constants.RESPONSE_WRITTEN, "true");
@@ -176,6 +176,6 @@
 			throw new SandeshaException(e1.getMessage());
 		}
 
-		createSeqMsg.setPausedTrue(new QName(Constants.IN_HANDLER_NAME));
+		createSeqMsg.setPausedTrue(new QName(Sandesha2Constants.IN_HANDLER_NAME));
 	}
 }

Modified: webservices/sandesha/trunk/src/org/apache/sandesha2/msgprocessors/CreateSeqResponseMsgProcessor.java
URL: http://svn.apache.org/viewcvs/webservices/sandesha/trunk/src/org/apache/sandesha2/msgprocessors/CreateSeqResponseMsgProcessor.java?rev=349889&r1=349888&r2=349889&view=diff
==============================================================================
--- webservices/sandesha/trunk/src/org/apache/sandesha2/msgprocessors/CreateSeqResponseMsgProcessor.java (original)
+++ webservices/sandesha/trunk/src/org/apache/sandesha2/msgprocessors/CreateSeqResponseMsgProcessor.java Tue Nov 29 22:03:23 2005
@@ -17,7 +17,7 @@
 
 package org.apache.sandesha2.msgprocessors;
 
-import org.apache.sandesha2.Constants;
+import org.apache.sandesha2.Sandesha2Constants;
 import org.apache.sandesha2.RMMsgContext;
 import org.apache.sandesha2.SandeshaException;
 import org.apache.sandesha2.storage.StorageManager;
@@ -62,7 +62,7 @@
 
 		//Processing for ack if any
 		SequenceAcknowledgement sequenceAck = (SequenceAcknowledgement) createSeqResponseRMMsgCtx
-				.getMessagePart(Constants.MessageParts.SEQ_ACKNOWLEDGEMENT);
+				.getMessagePart(Sandesha2Constants.MessageParts.SEQ_ACKNOWLEDGEMENT);
 		if (sequenceAck != null) {
 			AcknowledgementProcessor ackProcessor = new AcknowledgementProcessor();
 			ackProcessor.processMessage(createSeqResponseRMMsgCtx);
@@ -70,7 +70,7 @@
 
 		//Processing the create sequence response.
 		CreateSequenceResponse createSeqResponsePart = (CreateSequenceResponse) createSeqResponseRMMsgCtx
-				.getMessagePart(Constants.MessageParts.CREATE_SEQ_RESPONSE);
+				.getMessagePart(Sandesha2Constants.MessageParts.CREATE_SEQ_RESPONSE);
 		if (createSeqResponsePart == null)
 			throw new SandeshaException("Create Sequence Response part is null");
 
@@ -106,11 +106,11 @@
 		SequencePropertyBeanMgr sequencePropMgr = storageManager
 				.getSequencePropretyBeanMgr();
 		SequencePropertyBean outSequenceBean = new SequencePropertyBean(
-				internalSequenceId, Constants.SequenceProperties.OUT_SEQUENCE_ID,
+				internalSequenceId, Sandesha2Constants.SequenceProperties.OUT_SEQUENCE_ID,
 				newOutSequenceId);
 		SequencePropertyBean internalSequenceBean = new SequencePropertyBean(
 				newOutSequenceId,
-				Constants.SequenceProperties.INTERNAL_SEQUENCE_ID, internalSequenceId);
+				Sandesha2Constants.SequenceProperties.INTERNAL_SEQUENCE_ID, internalSequenceId);
 		sequencePropMgr.insert(outSequenceBean);
 		sequencePropMgr.insert(internalSequenceBean);
 
@@ -120,7 +120,7 @@
 			//Find offered sequence from internal sequence id.
 			SequencePropertyBean offeredSequenceBean = sequencePropMgr
 					.retrieve(internalSequenceId,
-							Constants.SequenceProperties.OFFERED_SEQUENCE);
+							Sandesha2Constants.SequenceProperties.OFFERED_SEQUENCE);
 
 			//TODO this should be detected in the Fault manager.
 			if (offeredSequenceBean == null)
@@ -132,7 +132,7 @@
 			EndpointReference acksToEPR = accept.getAcksTo().getAddress()
 					.getEpr();
 			SequencePropertyBean acksToBean = new SequencePropertyBean();
-			acksToBean.setName(Constants.SequenceProperties.ACKS_TO_EPR);
+			acksToBean.setName(Sandesha2Constants.SequenceProperties.ACKS_TO_EPR);
 			acksToBean.setSequenceId(offeredSequenceId);
 			acksToBean.setValue(acksToEPR);
 
@@ -162,7 +162,7 @@
 					.initializeMessage(applicationMsg);
 
 			Sequence sequencePart = (Sequence) applicaionRMMsg
-					.getMessagePart(Constants.MessageParts.SEQUENCE);
+					.getMessagePart(Sandesha2Constants.MessageParts.SEQUENCE);
 			if (sequencePart == null)
 				throw new SandeshaException("Sequence part is null");
 
@@ -172,7 +172,7 @@
 			sequencePart.setIdentifier(identifier);
 
 			AckRequested ackRequestedPart = (AckRequested) applicaionRMMsg
-					.getMessagePart(Constants.MessageParts.ACK_REQUEST);
+					.getMessagePart(Sandesha2Constants.MessageParts.ACK_REQUEST);
 			if (ackRequestedPart != null) {
 				Identifier id1 = new Identifier(factory);
 				id1.setIndentifer(newOutSequenceId);
@@ -195,6 +195,6 @@
 						"false");
 
 		createSeqResponseRMMsgCtx.getMessageContext().setPausedTrue(
-				new QName(Constants.IN_HANDLER_NAME));
+				new QName(Sandesha2Constants.IN_HANDLER_NAME));
 	}
 }

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=349889&r1=349888&r2=349889&view=diff
==============================================================================
--- webservices/sandesha/trunk/src/org/apache/sandesha2/msgprocessors/MsgProcessorFactory.java (original)
+++ webservices/sandesha/trunk/src/org/apache/sandesha2/msgprocessors/MsgProcessorFactory.java Tue Nov 29 22:03:23 2005
@@ -17,7 +17,7 @@
 
 package org.apache.sandesha2.msgprocessors;
 
-import org.apache.sandesha2.Constants;
+import org.apache.sandesha2.Sandesha2Constants;
 
 /**
  * Used to get a suitable message processor. Given the message type.
@@ -29,15 +29,15 @@
 
 	public static MsgProcessor getMessageProcessor(int msgType) {
 		switch (msgType) {
-		case (Constants.MessageTypes.CREATE_SEQ):
+		case (Sandesha2Constants.MessageTypes.CREATE_SEQ):
 			return new CreateSeqMsgProcessor();
-		case (Constants.MessageTypes.TERMINATE_SEQ):
+		case (Sandesha2Constants.MessageTypes.TERMINATE_SEQ):
 			return new TerminateSeqMsgProcessor();
-		case (Constants.MessageTypes.APPLICATION):
+		case (Sandesha2Constants.MessageTypes.APPLICATION):
 			return new ApplicationMsgProcessor();
-		case (Constants.MessageTypes.CREATE_SEQ_RESPONSE):
+		case (Sandesha2Constants.MessageTypes.CREATE_SEQ_RESPONSE):
 			return new CreateSeqResponseMsgProcessor();
-		case (Constants.MessageTypes.ACK):
+		case (Sandesha2Constants.MessageTypes.ACK):
 			return new AcknowledgementProcessor();
 		default:
 			return null;

Modified: webservices/sandesha/trunk/src/org/apache/sandesha2/msgprocessors/TerminateSeqMsgProcessor.java
URL: http://svn.apache.org/viewcvs/webservices/sandesha/trunk/src/org/apache/sandesha2/msgprocessors/TerminateSeqMsgProcessor.java?rev=349889&r1=349888&r2=349889&view=diff
==============================================================================
--- webservices/sandesha/trunk/src/org/apache/sandesha2/msgprocessors/TerminateSeqMsgProcessor.java (original)
+++ webservices/sandesha/trunk/src/org/apache/sandesha2/msgprocessors/TerminateSeqMsgProcessor.java Tue Nov 29 22:03:23 2005
@@ -21,7 +21,7 @@
 
 import org.apache.axis2.context.ConfigurationContext;
 import org.apache.axis2.context.MessageContext;
-import org.apache.sandesha2.Constants;
+import org.apache.sandesha2.Sandesha2Constants;
 import org.apache.sandesha2.RMMsgContext;
 import org.apache.sandesha2.SandeshaException;
 import org.apache.sandesha2.TerminateManager;
@@ -47,7 +47,7 @@
 		MessageContext terminateSeqMsg = terminateSeqRMMSg.getMessageContext();
 		//Processing for ack if any
 		SequenceAcknowledgement sequenceAck = (SequenceAcknowledgement) terminateSeqRMMSg
-				.getMessagePart(Constants.MessageParts.SEQ_ACKNOWLEDGEMENT);
+				.getMessagePart(Sandesha2Constants.MessageParts.SEQ_ACKNOWLEDGEMENT);
 		if (sequenceAck != null) {
 			AcknowledgementProcessor ackProcessor = new AcknowledgementProcessor();
 			ackProcessor.processMessage(terminateSeqRMMSg);
@@ -55,7 +55,7 @@
 
 		//Processing the terminate message
 		//TODO Add terminate sequence message logic.
-		TerminateSequence terminateSequence = (TerminateSequence) terminateSeqRMMSg.getMessagePart(Constants.MessageParts.TERMINATE_SEQ);
+		TerminateSequence terminateSequence = (TerminateSequence) terminateSeqRMMSg.getMessagePart(Sandesha2Constants.MessageParts.TERMINATE_SEQ);
 		if (terminateSequence==null)
 			throw new SandeshaException ("Terminate Sequence part is not available");
 		
@@ -69,7 +69,7 @@
 		TerminateManager.terminateReceivingSide(context,sequenceId);
 		
 
-		terminateSeqMsg.setPausedTrue(new QName(Constants.IN_HANDLER_NAME));
+		terminateSeqMsg.setPausedTrue(new QName(Sandesha2Constants.IN_HANDLER_NAME));
 
 	}
 }

Modified: webservices/sandesha/trunk/src/org/apache/sandesha2/policy/RMPolicyBean.java
URL: http://svn.apache.org/viewcvs/webservices/sandesha/trunk/src/org/apache/sandesha2/policy/RMPolicyBean.java?rev=349889&r1=349888&r2=349889&view=diff
==============================================================================
--- webservices/sandesha/trunk/src/org/apache/sandesha2/policy/RMPolicyBean.java (original)
+++ webservices/sandesha/trunk/src/org/apache/sandesha2/policy/RMPolicyBean.java Tue Nov 29 22:03:23 2005
@@ -24,7 +24,7 @@
 
 package org.apache.sandesha2.policy;
 
-import org.apache.sandesha2.Constants;
+import org.apache.sandesha2.Sandesha2Constants;
 
 public class RMPolicyBean {
     private long inactiveTimeoutInterval;

Modified: webservices/sandesha/trunk/src/org/apache/sandesha2/storage/beans/SenderBean.java
URL: http://svn.apache.org/viewcvs/webservices/sandesha/trunk/src/org/apache/sandesha2/storage/beans/SenderBean.java?rev=349889&r1=349888&r2=349889&view=diff
==============================================================================
--- webservices/sandesha/trunk/src/org/apache/sandesha2/storage/beans/SenderBean.java (original)
+++ webservices/sandesha/trunk/src/org/apache/sandesha2/storage/beans/SenderBean.java Tue Nov 29 22:03:23 2005
@@ -79,7 +79,7 @@
 	/**
 	 * Comment for <code>messagetype</code>
 	 * The type of the current message.
-	 * Possible types are given in Constants.MessageTypes interface.
+	 * Possible types are given in Sandesha2Constants.MessageTypes interface.
 	 */
 	private int messagetype =0;
 	

Modified: webservices/sandesha/trunk/src/org/apache/sandesha2/storage/beans/SequencePropertyBean.java
URL: http://svn.apache.org/viewcvs/webservices/sandesha/trunk/src/org/apache/sandesha2/storage/beans/SequencePropertyBean.java?rev=349889&r1=349888&r2=349889&view=diff
==============================================================================
--- webservices/sandesha/trunk/src/org/apache/sandesha2/storage/beans/SequencePropertyBean.java (original)
+++ webservices/sandesha/trunk/src/org/apache/sandesha2/storage/beans/SequencePropertyBean.java Tue Nov 29 22:03:23 2005
@@ -34,7 +34,7 @@
 
 	/**
 	 * Comment for <code>name</code>
-	 * The name of the property. Possible names are given in the Constants.SequenceProperties interface.
+	 * The name of the property. Possible names are given in the Sandesha2Constants.SequenceProperties interface.
 	 */
 	private String name;
 

Modified: webservices/sandesha/trunk/src/org/apache/sandesha2/storage/inmemory/InMemoryCreateSeqBeanMgr.java
URL: http://svn.apache.org/viewcvs/webservices/sandesha/trunk/src/org/apache/sandesha2/storage/inmemory/InMemoryCreateSeqBeanMgr.java?rev=349889&r1=349888&r2=349889&view=diff
==============================================================================
--- webservices/sandesha/trunk/src/org/apache/sandesha2/storage/inmemory/InMemoryCreateSeqBeanMgr.java (original)
+++ webservices/sandesha/trunk/src/org/apache/sandesha2/storage/inmemory/InMemoryCreateSeqBeanMgr.java Tue Nov 29 22:03:23 2005
@@ -23,7 +23,7 @@
 import java.util.Iterator;
 
 import org.apache.axis2.context.AbstractContext;
-import org.apache.sandesha2.Constants;
+import org.apache.sandesha2.Sandesha2Constants;
 import org.apache.sandesha2.storage.beanmanagers.CreateSeqBeanMgr;
 import org.apache.sandesha2.storage.beans.CreateSeqBean;
 
@@ -37,12 +37,12 @@
 	private Hashtable table = null;
 
 	public InMemoryCreateSeqBeanMgr(AbstractContext context) {
-		Object obj = context.getProperty(Constants.BeanMAPs.CREATE_SEQUECE);
+		Object obj = context.getProperty(Sandesha2Constants.BeanMAPs.CREATE_SEQUECE);
 		if (obj != null) {
 			table = (Hashtable) obj;
 		} else {
 			table = new Hashtable();
-			context.setProperty(Constants.BeanMAPs.CREATE_SEQUECE, table);
+			context.setProperty(Sandesha2Constants.BeanMAPs.CREATE_SEQUECE, table);
 		}
 	}
 

Modified: webservices/sandesha/trunk/src/org/apache/sandesha2/storage/inmemory/InMemoryInvokerBeanMgr.java
URL: http://svn.apache.org/viewcvs/webservices/sandesha/trunk/src/org/apache/sandesha2/storage/inmemory/InMemoryInvokerBeanMgr.java?rev=349889&r1=349888&r2=349889&view=diff
==============================================================================
--- webservices/sandesha/trunk/src/org/apache/sandesha2/storage/inmemory/InMemoryInvokerBeanMgr.java (original)
+++ webservices/sandesha/trunk/src/org/apache/sandesha2/storage/inmemory/InMemoryInvokerBeanMgr.java Tue Nov 29 22:03:23 2005
@@ -22,7 +22,7 @@
 import java.util.Hashtable;
 import java.util.Iterator;
 import org.apache.axis2.context.AbstractContext;
-import org.apache.sandesha2.Constants;
+import org.apache.sandesha2.Sandesha2Constants;
 import org.apache.sandesha2.storage.beanmanagers.InvokerBeanMgr;
 import org.apache.sandesha2.storage.beans.InvokerBean;
 
@@ -35,12 +35,12 @@
 	private Hashtable table = null;
 
 	public InMemoryInvokerBeanMgr(AbstractContext context) {
-		Object obj = context.getProperty(Constants.BeanMAPs.STORAGE_MAP);
+		Object obj = context.getProperty(Sandesha2Constants.BeanMAPs.STORAGE_MAP);
 		if (obj != null) {
 			table = (Hashtable) obj;
 		} else {
 			table = new Hashtable();
-			context.setProperty(Constants.BeanMAPs.STORAGE_MAP, table);
+			context.setProperty(Sandesha2Constants.BeanMAPs.STORAGE_MAP, table);
 		}
 	}
 

Modified: webservices/sandesha/trunk/src/org/apache/sandesha2/storage/inmemory/InMemoryNextMsgBeanMgr.java
URL: http://svn.apache.org/viewcvs/webservices/sandesha/trunk/src/org/apache/sandesha2/storage/inmemory/InMemoryNextMsgBeanMgr.java?rev=349889&r1=349888&r2=349889&view=diff
==============================================================================
--- webservices/sandesha/trunk/src/org/apache/sandesha2/storage/inmemory/InMemoryNextMsgBeanMgr.java (original)
+++ webservices/sandesha/trunk/src/org/apache/sandesha2/storage/inmemory/InMemoryNextMsgBeanMgr.java Tue Nov 29 22:03:23 2005
@@ -23,7 +23,7 @@
 import java.util.Iterator;
 
 import org.apache.axis2.context.AbstractContext;
-import org.apache.sandesha2.Constants;
+import org.apache.sandesha2.Sandesha2Constants;
 import org.apache.sandesha2.storage.beanmanagers.NextMsgBeanMgr;
 import org.apache.sandesha2.storage.beans.NextMsgBean;
 
@@ -37,13 +37,13 @@
 	private Hashtable table = null;
 
 	public InMemoryNextMsgBeanMgr(AbstractContext context) {
-		Object obj = context.getProperty(Constants.BeanMAPs.NEXT_MESSAGE);
+		Object obj = context.getProperty(Sandesha2Constants.BeanMAPs.NEXT_MESSAGE);
 
 		if (obj != null) {
 			table = (Hashtable) obj;
 		} else {
 			table = new Hashtable();
-			context.setProperty(Constants.BeanMAPs.NEXT_MESSAGE, table);
+			context.setProperty(Sandesha2Constants.BeanMAPs.NEXT_MESSAGE, table);
 		}
 	}
 

Modified: webservices/sandesha/trunk/src/org/apache/sandesha2/storage/inmemory/InMemorySenderBeanMgr.java
URL: http://svn.apache.org/viewcvs/webservices/sandesha/trunk/src/org/apache/sandesha2/storage/inmemory/InMemorySenderBeanMgr.java?rev=349889&r1=349888&r2=349889&view=diff
==============================================================================
--- webservices/sandesha/trunk/src/org/apache/sandesha2/storage/inmemory/InMemorySenderBeanMgr.java (original)
+++ webservices/sandesha/trunk/src/org/apache/sandesha2/storage/inmemory/InMemorySenderBeanMgr.java Tue Nov 29 22:03:23 2005
@@ -24,7 +24,7 @@
 import java.util.Iterator;
 
 import org.apache.axis2.context.AbstractContext;
-import org.apache.sandesha2.Constants;
+import org.apache.sandesha2.Sandesha2Constants;
 import org.apache.sandesha2.SandeshaException;
 import org.apache.sandesha2.storage.beanmanagers.SenderBeanMgr;
 import org.apache.sandesha2.storage.beans.SenderBean;
@@ -38,12 +38,12 @@
 	private Hashtable table = null;
 
 	public InMemorySenderBeanMgr(AbstractContext context) {
-		Object obj = context.getProperty(Constants.BeanMAPs.RETRANSMITTER);
+		Object obj = context.getProperty(Sandesha2Constants.BeanMAPs.RETRANSMITTER);
 		if (obj != null) {
 			table = (Hashtable) obj;
 		} else {
 			table = new Hashtable();
-			context.setProperty(Constants.BeanMAPs.RETRANSMITTER, table);
+			context.setProperty(Sandesha2Constants.BeanMAPs.RETRANSMITTER, table);
 		}
 	}
 
@@ -97,7 +97,7 @@
 					&& bean.getMessageNumber() != temp.getMessageNumber())
 				add = false;
 
-			if (bean.getMessagetype() != Constants.MessageTypes.UNKNOWN
+			if (bean.getMessagetype() != Sandesha2Constants.MessageTypes.UNKNOWN
 					&& bean.getMessagetype() != temp.getMessagetype())
 				add = false;
 

Modified: webservices/sandesha/trunk/src/org/apache/sandesha2/storage/inmemory/InMemorySequencePropertyBeanMgr.java
URL: http://svn.apache.org/viewcvs/webservices/sandesha/trunk/src/org/apache/sandesha2/storage/inmemory/InMemorySequencePropertyBeanMgr.java?rev=349889&r1=349888&r2=349889&view=diff
==============================================================================
--- webservices/sandesha/trunk/src/org/apache/sandesha2/storage/inmemory/InMemorySequencePropertyBeanMgr.java (original)
+++ webservices/sandesha/trunk/src/org/apache/sandesha2/storage/inmemory/InMemorySequencePropertyBeanMgr.java Tue Nov 29 22:03:23 2005
@@ -23,7 +23,7 @@
 import java.util.Iterator;
 
 import org.apache.axis2.context.AbstractContext;
-import org.apache.sandesha2.Constants;
+import org.apache.sandesha2.Sandesha2Constants;
 import org.apache.sandesha2.storage.beanmanagers.SequencePropertyBeanMgr;
 import org.apache.sandesha2.storage.beans.SequencePropertyBean;
 
@@ -36,12 +36,12 @@
 	private Hashtable table = null;
 
 	public InMemorySequencePropertyBeanMgr(AbstractContext context) {
-		Object obj = context.getProperty(Constants.BeanMAPs.SEQUENCE_PROPERTY);
+		Object obj = context.getProperty(Sandesha2Constants.BeanMAPs.SEQUENCE_PROPERTY);
 		if (obj != null) {
 			table = (Hashtable) obj;
 		} else {
 			table = new Hashtable();
-			context.setProperty(Constants.BeanMAPs.SEQUENCE_PROPERTY, table);
+			context.setProperty(Sandesha2Constants.BeanMAPs.SEQUENCE_PROPERTY, table);
 		}
 	}
 

Modified: webservices/sandesha/trunk/src/org/apache/sandesha2/util/FaultManager.java
URL: http://svn.apache.org/viewcvs/webservices/sandesha/trunk/src/org/apache/sandesha2/util/FaultManager.java?rev=349889&r1=349888&r2=349889&view=diff
==============================================================================
--- webservices/sandesha/trunk/src/org/apache/sandesha2/util/FaultManager.java (original)
+++ webservices/sandesha/trunk/src/org/apache/sandesha2/util/FaultManager.java Tue Nov 29 22:03:23 2005
@@ -35,7 +35,7 @@
 import org.apache.axis2.soap.SOAPFactory;
 import org.apache.axis2.soap.SOAPHeader;
 import org.apache.axis2.util.Utils;
-import org.apache.sandesha2.Constants;
+import org.apache.sandesha2.Sandesha2Constants;
 import org.apache.sandesha2.FaultData;
 import org.apache.sandesha2.RMMsgContext;
 import org.apache.sandesha2.SOAPFaultEnvelopeCreator;
@@ -81,8 +81,8 @@
 		SOAPHeader header = envelope.getHeader();
 		if (header != null) {
 			OMElement sequenceHeaderBlock = header
-					.getFirstChildWithName(new QName(Constants.WSRM.NS_URI_RM,
-							Constants.WSRM.SEQUENCE));
+					.getFirstChildWithName(new QName(Sandesha2Constants.WSRM.NS_URI_RM,
+							Sandesha2Constants.WSRM.SEQUENCE));
 			if (sequenceHeaderBlock != null) {
 				faultMessageContext = checkForMessageNumberRoleover(msgCtx);
 				if (faultMessageContext != null)
@@ -93,27 +93,27 @@
 		RMMsgContext rmMsgCtx = MsgInitializer.initializeMessage(msgCtx);
 		int msgType = rmMsgCtx.getMessageType();
 
-		if (msgType == Constants.MessageTypes.APPLICATION
-				|| msgType == Constants.MessageTypes.TERMINATE_SEQ) {
+		if (msgType == Sandesha2Constants.MessageTypes.APPLICATION
+				|| msgType == Sandesha2Constants.MessageTypes.TERMINATE_SEQ) {
 			faultMessageContext = checkForUnknownSequence(msgCtx);
 			if (faultMessageContext != null)
 				return faultMessageContext;
 
 		}
 
-		if (msgType == Constants.MessageTypes.CREATE_SEQ) {
+		if (msgType == Sandesha2Constants.MessageTypes.CREATE_SEQ) {
 			faultMessageContext = checkForCreateSequenceRefused(msgCtx);
 			if (faultMessageContext != null)
 				return faultMessageContext;
 		}
 
-		if (msgType == Constants.MessageTypes.ACK) {
+		if (msgType == Sandesha2Constants.MessageTypes.ACK) {
 			faultMessageContext = checkForInvalidAcknowledgement(msgCtx);
 			if (faultMessageContext != null)
 				return faultMessageContext;
 		}
 
-		if (msgType == Constants.MessageTypes.APPLICATION) {
+		if (msgType == Sandesha2Constants.MessageTypes.APPLICATION) {
 			faultMessageContext = checkForLastMsgNumberExceeded(msgCtx);
 			if (faultMessageContext != null)
 				return faultMessageContext;
@@ -137,7 +137,7 @@
 				.initializeMessage(messageContext);
 
 		CreateSequence createSequence = (CreateSequence) rmMsgCtx
-				.getMessagePart(Constants.MessageParts.CREATE_SEQ);
+				.getMessagePart(Sandesha2Constants.MessageParts.CREATE_SEQ);
 		if (createSequence == null)
 			throw new SandeshaException(
 					"CreateSequence message does not have a CreateSequence part");
@@ -180,7 +180,7 @@
 					SequencePropertyBean sequencePropertyBean = sequencePropertyBeanMgr
 							.retrieve(
 									sequenceId,
-									Constants.SequenceProperties.OUT_SEQUENCE_ID);
+									Sandesha2Constants.SequenceProperties.OUT_SEQUENCE_ID);
 					if (sequencePropertyBean != null) {
 						String outSequenceId = (String) sequencePropertyBean
 								.getValue();
@@ -201,17 +201,17 @@
 
 			FaultData data = new FaultData();
 			data
-					.setType(Constants.SOAPFaults.FaultType.CREATE_SEQUENCE_REFUSED);
+					.setType(Sandesha2Constants.SOAPFaults.FaultType.CREATE_SEQUENCE_REFUSED);
 
 			int SOAPVersion = SandeshaUtil.getSOAPVersion(rmMsgCtx
 					.getSOAPEnvelope());
-			if (SOAPVersion == Constants.SOAPVersion.v1_1)
+			if (SOAPVersion == Sandesha2Constants.SOAPVersion.v1_1)
 				data.setCode(SOAP11Constants.FAULT_CODE_SENDER);
 			else
 				data.setCode(SOAP12Constants.FAULT_CODE_SENDER);
 
 			data
-					.setSubcode(Constants.SOAPFaults.Subcodes.CREATE_SEQUENCE_REFUSED);
+					.setSubcode(Sandesha2Constants.SOAPFaults.Subcodes.CREATE_SEQUENCE_REFUSED);
 			data.setReason(reason);
 			return getFault(rmMsgCtx, data);
 		}
@@ -251,23 +251,23 @@
 				.initializeMessage(messageContext);
 		String sequenceId = null;
 
-		if (rmMsgCtx.getMessageType() == Constants.MessageTypes.APPLICATION) {
+		if (rmMsgCtx.getMessageType() == Sandesha2Constants.MessageTypes.APPLICATION) {
 			Sequence sequence = (Sequence) rmMsgCtx
-					.getMessagePart(Constants.MessageParts.SEQUENCE);
+					.getMessagePart(Sandesha2Constants.MessageParts.SEQUENCE);
 			if (sequence == null)
 				throw new SandeshaException(
 						"Sequence part not found in the application message");
 
 			sequenceId = sequence.getIdentifier().getIdentifier();
 
-		} else if (rmMsgCtx.getMessageType() == Constants.MessageTypes.ACK) {
+		} else if (rmMsgCtx.getMessageType() == Sandesha2Constants.MessageTypes.ACK) {
 			SequenceAcknowledgement sequenceAcknowledgement = (SequenceAcknowledgement) rmMsgCtx
-					.getMessagePart(Constants.MessageParts.SEQ_ACKNOWLEDGEMENT);
+					.getMessagePart(Sandesha2Constants.MessageParts.SEQ_ACKNOWLEDGEMENT);
 			sequenceId = sequenceAcknowledgement.getIdentifier()
 					.getIdentifier();
-		} else if (rmMsgCtx.getMessageType() == Constants.MessageTypes.TERMINATE_SEQ) {
+		} else if (rmMsgCtx.getMessageType() == Sandesha2Constants.MessageTypes.TERMINATE_SEQ) {
 			TerminateSequence terminateSequence = (TerminateSequence) rmMsgCtx
-					.getMessagePart(Constants.MessageParts.TERMINATE_SEQ);
+					.getMessagePart(Sandesha2Constants.MessageParts.TERMINATE_SEQ);
 			sequenceId = terminateSequence.getIdentifier().getIdentifier();
 		} else {
 			//sequenceId not found.
@@ -299,12 +299,12 @@
 			int SOAPVersion = SandeshaUtil.getSOAPVersion(envelope);
 
 			FaultData data = new FaultData();
-			if (SOAPVersion == Constants.SOAPVersion.v1_1)
+			if (SOAPVersion == Sandesha2Constants.SOAPVersion.v1_1)
 				data.setCode(SOAP11Constants.FAULT_CODE_SENDER);
 			else
 				data.setCode(SOAP12Constants.FAULT_CODE_SENDER);
 
-			data.setSubcode(Constants.SOAPFaults.Subcodes.UNKNOWN_SEQUENCE);
+			data.setSubcode(Sandesha2Constants.SOAPFaults.Subcodes.UNKNOWN_SEQUENCE);
 
 			SOAPFactory factory = SOAPAbstractFactory
 					.getSOAPFactory(SOAPVersion);
@@ -335,11 +335,11 @@
 		//check lower<=upper
 		//TODO acked for not-send message
 		RMMsgContext rmMsgContext = new RMMsgContext();
-		if (rmMsgContext.getMessageType() != Constants.MessageTypes.ACK)
+		if (rmMsgContext.getMessageType() != Sandesha2Constants.MessageTypes.ACK)
 			return null;
 
 		SequenceAcknowledgement sequenceAcknowledgement = (SequenceAcknowledgement) rmMsgContext
-				.getMessagePart(Constants.MessageParts.SEQ_ACKNOWLEDGEMENT);
+				.getMessagePart(Sandesha2Constants.MessageParts.SEQ_ACKNOWLEDGEMENT);
 		List sequenceAckList = sequenceAcknowledgement
 				.getAcknowledgementRanges();
 		Iterator it = sequenceAckList.iterator();
@@ -355,12 +355,12 @@
 				FaultData data = new FaultData();
 				int SOAPVersion = SandeshaUtil.getSOAPVersion(msgCtx
 						.getEnvelope());
-				if (SOAPVersion == Constants.SOAPVersion.v1_1)
+				if (SOAPVersion == Sandesha2Constants.SOAPVersion.v1_1)
 					data.setCode(SOAP11Constants.FAULT_CODE_SENDER);
 				else
 					data.setCode(SOAP12Constants.FAULT_CODE_SENDER);
 
-				data.setSubcode(Constants.SOAPFaults.Subcodes.INVALID_ACKNOWLEDGEMENT);
+				data.setSubcode(Sandesha2Constants.SOAPFaults.Subcodes.INVALID_ACKNOWLEDGEMENT);
 				data.setSubcode("The SequenceAcknowledgement is invalid. Lower value is larger than upper value");
 				data.setDetail(sequenceAcknowledgement.getOMElement());
 
@@ -418,9 +418,9 @@
 			faultMsgContext.setOperationContext(operationContext);
 
 			String acksToStr = null;
-			if (referenceRMMsgContext.getMessageType() == Constants.MessageTypes.CREATE_SEQ) {
+			if (referenceRMMsgContext.getMessageType() == Sandesha2Constants.MessageTypes.CREATE_SEQ) {
 				CreateSequence createSequence = (CreateSequence) referenceRMMsgContext
-						.getMessagePart(Constants.MessageParts.CREATE_SEQ);
+						.getMessagePart(Sandesha2Constants.MessageParts.CREATE_SEQ);
 				acksToStr = createSequence.getAcksTo().getAddress().getEpr()
 						.getAddress();
 			} else {
@@ -428,7 +428,7 @@
 						.getSequencePropretyBeanMgr();
 				String sequenceId = data.getSequenceId();
 				SequencePropertyBean acksToBean = seqPropMgr.retrieve(
-						sequenceId, Constants.SequenceProperties.ACKS_TO_EPR);
+						sequenceId, Sandesha2Constants.SequenceProperties.ACKS_TO_EPR);
 				if (acksToBean != null) {
 					EndpointReference epr = (EndpointReference) acksToBean
 							.getValue();
@@ -438,7 +438,7 @@
 			}
 
 			if (acksToStr != null
-					&& !acksToStr.equals(Constants.WSA.NS_URI_ANONYMOUS)) {
+					&& !acksToStr.equals(Sandesha2Constants.WSA.NS_URI_ANONYMOUS)) {
 				faultMsgContext.setTo(new EndpointReference(acksToStr));
 			}
 

Modified: webservices/sandesha/trunk/src/org/apache/sandesha2/util/MessageRetransmissionAdjuster.java
URL: http://svn.apache.org/viewcvs/webservices/sandesha/trunk/src/org/apache/sandesha2/util/MessageRetransmissionAdjuster.java?rev=349889&r1=349888&r2=349889&view=diff
==============================================================================
--- webservices/sandesha/trunk/src/org/apache/sandesha2/util/MessageRetransmissionAdjuster.java (original)
+++ webservices/sandesha/trunk/src/org/apache/sandesha2/util/MessageRetransmissionAdjuster.java Tue Nov 29 22:03:23 2005
@@ -18,7 +18,7 @@
 package org.apache.sandesha2.util;
 
 import org.apache.axis2.context.MessageContext;
-import org.apache.sandesha2.Constants;
+import org.apache.sandesha2.Sandesha2Constants;
 import org.apache.sandesha2.policy.RMPolicyBean;
 import org.apache.sandesha2.storage.beans.SenderBean;
 
@@ -44,7 +44,7 @@
 			return retransmitterBean;
 
 		RMPolicyBean policyBean = (RMPolicyBean) messageContext
-				.getProperty(Constants.WSP.RM_POLICY_BEAN);
+				.getProperty(Sandesha2Constants.WSP.RM_POLICY_BEAN);
 		if (policyBean == null) {
 			//loading default policies.
 			policyBean = PropertyManager.getInstance().getRMPolicyBean();
@@ -53,7 +53,7 @@
 		retransmitterBean.setSentCount(retransmitterBean.getSentCount() + 1);
 		adjustNextRetransmissionTime(retransmitterBean, policyBean);
 
-		if (retransmitterBean.getSentCount() >= Constants.MAXIMUM_RETRANSMISSION_ATTEMPTS)
+		if (retransmitterBean.getSentCount() >= Sandesha2Constants.MAXIMUM_RETRANSMISSION_ATTEMPTS)
 			stopRetransmission(retransmitterBean);
 
 		return retransmitterBean;



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