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/29 12:34:26 UTC

svn commit: r349710 - in /webservices/sandesha/trunk/src/org/apache/sandesha2: ./ handlers/ msgprocessors/ storage/beans/ storage/inmemory/ util/

Author: chamikara
Date: Tue Nov 29 03:32:54 2005
New Revision: 349710

URL: http://svn.apache.org/viewcvs?rev=349710&view=rev
Log:
Removed unnecessary comments.

Removed:
    webservices/sandesha/trunk/src/org/apache/sandesha2/SandeshaDynamicProperties.java
Modified:
    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/storage/beans/SenderBean.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/storage/inmemory/InMemoryStorageManager.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/SandeshaUtil.java
    webservices/sandesha/trunk/src/org/apache/sandesha2/util/SequenceManager.java

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=349710&r1=349709&r2=349710&view=diff
==============================================================================
--- webservices/sandesha/trunk/src/org/apache/sandesha2/RMMsgContext.java (original)
+++ webservices/sandesha/trunk/src/org/apache/sandesha2/RMMsgContext.java Tue Nov 29 03:32:54 2005
@@ -169,12 +169,6 @@
 		}
 	}
 
-	public void test() {
-		String opearaitonName = msgContext.getOperationContext()
-				.getAxisOperation().getName().getLocalPart();
-		System.out.println("Operation is:" + opearaitonName);
-	}
-
 	public void serializeSOAPEnvelop() {
 		try {
 			SOAPEnvelope envelop = msgContext.getEnvelope();

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=349710&r1=349709&r2=349710&view=diff
==============================================================================
--- webservices/sandesha/trunk/src/org/apache/sandesha2/SOAPFaultEnvelopeCreator.java (original)
+++ webservices/sandesha/trunk/src/org/apache/sandesha2/SOAPFaultEnvelopeCreator.java Tue Nov 29 03:32:54 2005
@@ -127,9 +127,6 @@
 	private static void doSOAP11Encoding(MessageContext faultMsgContext,
 			FaultData data) throws SandeshaException {
 
-		//MessageContext faultMsgContext =
-		// faultRMMsgContext.getMessageContext();
-
 		SOAPEnvelope faultMsgEnvelope = faultMsgContext.getEnvelope();
 		if (faultMsgEnvelope == null)
 			throw new SandeshaException("SOAP Envelope is null");
@@ -172,7 +169,6 @@
 	 */
 	private static void doSOAP12Encoding(MessageContext faultMsgContext,
 			FaultData data) throws SandeshaException {
-		//MessageContext faultMsgCtx = faultRMMsgContext.getMessageContext();
 
 		SOAPEnvelope faultEnvelope = faultMsgContext.getEnvelope();
 		if (faultEnvelope == null)
@@ -207,87 +203,6 @@
 			faultDetail.addChild(detailElement);
 
 		faultMsgContext.setWSAAction(Constants.WSA.SOAP_FAULT_ACTION);
-
-		//		if (detailElement!=null) {
-		//			String subcode = data.getSubcode();
-		//			
-		//			if (Constants.SOAPFaults.Subcodes.SequenceTerminated.equals(subcode))
-		// {
-		//				
-		//			}else if
-		// (Constants.SOAPFaults.Subcodes.UnknownSequence.equals(subcode)) {
-		//				
-		//			}else if
-		// (Constants.SOAPFaults.Subcodes.InvalidAcknowledgement.equals(subcode))
-		// {
-		//				
-		//			}else if
-		// (Constants.SOAPFaults.Subcodes.MessageNumberRoleover.equals(subcode))
-		// {
-		//				
-		//			}else if
-		// (Constants.SOAPFaults.Subcodes.LastMessageNumberExceeded.equals(subcode))
-		// {
-		//				
-		//			}else if
-		// (Constants.SOAPFaults.Subcodes.CreateSequenceRefused.equals(subcode))
-		// {
-		//				
-		//			}
-
-		//		switch (data.type) {
-		//		case Constants.MessageTypes.APPLICATION:
-		//
-		//			/* Sequence */
-		//			OMElement sequence = ienvelope.getHeader()
-		//					.getFirstChildWithName(
-		//							new QName(Constants.WSRM.NS_URI_RM,
-		//									Constants.WSRM.SEQUENCE));
-		//			OMElement sidentifier = sequence.getFirstChildWithName(new QName(
-		//					Constants.WSRM.NS_URI_RM, Constants.WSRM.IDENTIFIER));
-		//
-		//			OMNamespace snamespace = factory.createOMNamespace(
-		//					Constants.WSRM.NS_URI_RM, Constants.WSRM.NS_PREFIX_RM);
-		//			OMElement selement = factory.createOMElement(
-		//					Constants.WSRM.IDENTIFIER, snamespace);
-		//
-		//			selement.setText(sidentifier.getText());
-		//			faultDetail.addChild(selement);
-		//			break;
-		//
-		//		case Constants.MessageTypes.ACK:
-		//
-		//			/* SequenceAcknowledge */
-		//
-		//			OMElement sequenceAck = ienvelope.getHeader()
-		//					.getFirstChildWithName(
-		//							new QName(Constants.WSRM.NS_URI_RM,
-		//									Constants.WSRM.SEQUENCE_ACK));
-		//			OMElement aidentifier = sequenceAck
-		//					.getFirstChildWithName(new QName(Constants.WSRM.NS_URI_RM,
-		//							Constants.WSRM.IDENTIFIER));
-		//			OMNamespace anamespace = factory.createOMNamespace(
-		//					Constants.WSRM.NS_URI_RM, Constants.WSRM.NS_PREFIX_RM);
-		//			OMElement aelement = factory.createOMElement(
-		//					Constants.WSRM.IDENTIFIER, anamespace);
-		//
-		//			aelement.setText(aidentifier.getText());
-		//			faultDetail.addChild(aelement);
-		//			break;
-		//
-		//		default:
-		//
-		//			/* TODO for other message types */
-		//			break;
-		//
-		//		}
-		//		}
-
-		//		try {
-		//			msgCtx.setEnvelope(envelope);
-		//		} catch (AxisFault e) {
-		//			throw new SandeshaException(e.getMessage());
-		//		}
 	}
 
 }

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=349710&r1=349709&r2=349710&view=diff
==============================================================================
--- webservices/sandesha/trunk/src/org/apache/sandesha2/TerminateManager.java (original)
+++ webservices/sandesha/trunk/src/org/apache/sandesha2/TerminateManager.java Tue Nov 29 03:32:54 2005
@@ -98,19 +98,6 @@
 			storageMapBeanMgr.delete(storageMapBean.getKey());
 		}
 		
-		//TODO - refine below (removing sequence properties of the receiving side).
-		//removing sequencePropertyEntries.
-//		SequencePropertyBean findSequencePropBean = new SequencePropertyBean ();
-//		findSequencePropBean.setSequenceId(sequenceID);
-//		collection = sequencePropertyBeanMgr.find(findSequencePropBean);
-//		iterator = collection.iterator();
-//		while (iterator.hasNext()) {
-//			SequencePropertyBean sequencePropertyBean = (SequencePropertyBean) iterator.next();
-//			boolean propertyRequiredForResponses = isRequiredForResponseSide (sequencePropertyBean.getName());
-//			if (!propertyRequiredForResponses)
-//				sequencePropertyBeanMgr.delete(sequencePropertyBean.getSequenceId(),sequencePropertyBean.getName());
-//		}
-		
 		SequencePropertyBean allSequenceBean = sequencePropertyBeanMgr.retrieve(Constants.SequenceProperties.ALL_SEQUENCES,Constants.SequenceProperties.INCOMING_SEQUENCE_LIST);
 		ArrayList allSequenceList = (ArrayList) allSequenceBean.getValue();
 		

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=349710&r1=349709&r2=349710&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 03:32:54 2005
@@ -57,9 +57,7 @@
 
 	public void invoke(MessageContext msgContext) throws AxisFault {
 
-		//try {
-
-		//Quit the message with minimum processing if not intended for RM.
+		//Quitting the message with minimum processing if not intended for RM.
 		boolean isRMGlobalMessage = SandeshaUtil.isRMGlobalMessage(msgContext);
 		if (!isRMGlobalMessage) {
 			return;
@@ -82,8 +80,6 @@
 		ConfigurationContext context = rmMessageContext.getMessageContext()
 				.getSystemContext();
 
-		//context.setProperty (Constants.SANDESHA_DEBUG_MODE,"on");
-
 		ServiceContext serviceContext = msgContext.getServiceContext();
 		Object debug = null;
 		if (serviceContext != null) {
@@ -113,12 +109,6 @@
 				.getMessageType())) {
 			doGlobalProcessing(rmMessageContext);
 		}
-
-		//		}catch (Exception e) {
-		//			e.getStackTrace();
-		//			throw new AxisFault ("Sandesha got an exception. See logs for
-		// details");
-		//		}
 	}
 
 	private boolean dropIfDuplicate(RMMsgContext rmMsgContext)
@@ -205,7 +195,6 @@
 						}
 					}
 				}
-				//if (rmMsgContext.get)
 			}
 		}
 

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=349710&r1=349709&r2=349710&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 03:32:54 2005
@@ -54,8 +54,6 @@
 
 	public void invoke(MessageContext msgCtx) throws AxisFault {
 	
-		//System.out.println("In Sandesha In Handler....");
-		
 		ConfigurationContext context = msgCtx.getSystemContext();
 		if (context == null)
 			throw new AxisFault("ConfigurationContext is null");
@@ -108,12 +106,6 @@
 			se.printStackTrace();
 			throw new AxisFault("Error in processing the message");
 		}
-
-		//		}catch (Exception e) {
-		//			e.getStackTrace();
-		//			throw new AxisFault ("Sandesha got an exception. See logs for
-		// details");
-		//		}
 
 	}
 

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=349710&r1=349709&r2=349710&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 03:32:54 2005
@@ -75,8 +75,6 @@
 
 	public void invoke(MessageContext msgCtx) throws AxisFault {
 
-		//try {
-
 		ConfigurationContext context = msgCtx.getSystemContext();
 		if (context == null)
 			throw new AxisFault("ConfigurationContext is null");
@@ -106,7 +104,6 @@
 			}
 		}
 
-		//TODO recheck
 		//continue only if an possible application message
 		if (!(rmMsgCtx.getMessageType() == Constants.MessageTypes.UNKNOWN)) {
 			return;
@@ -139,7 +136,8 @@
 		//Temp sequence id is the one used to refer to the sequence (since
 		//actual sequence id is not available when first msg arrives)
 		//server side - sequenceId if the incoming sequence
-		//client side - xxxxxxxxx
+		//client side - wsaTo + SeequenceKey
+
 		if (serverSide) {
 			//getting the request message and rmMessage.
 			MessageContext reqMsgCtx = msgCtx.getOperationContext()
@@ -175,30 +173,20 @@
 
 		}
 
-		//check if the fist message
+		//check if the first message
 
 		long messageNumber = getNextMsgNo(context, internalSequenceId);
 
 		boolean sendCreateSequence = false;
 
-		SequencePropertyBean outSeqBean = seqPropMgr.retrieve(internalSequenceId,
+		SequencePropertyBean outSeqBean = seqPropMgr.retrieve(
+				internalSequenceId,
 				Constants.SequenceProperties.OUT_SEQUENCE_ID);
 
 		if (messageNumber == 1) {
 			if (outSeqBean == null) {
 				sendCreateSequence = true;
 			}
-
-			//			SandeshaDynamicProperties dynamicProperties =
-			// SandeshaUtil.getDynamicProperties();
-			//			if (msgCtx.isSOAP11()) {
-			//				dynamicProperties.setSOAPVersionURI(SOAP11Constants.SOAP_ENVELOPE_NAMESPACE_URI);
-			//			}else {
-			//				dynamicProperties.setSOAPVersionURI(SOAP12Constants.SOAP_ENVELOPE_NAMESPACE_URI);
-			//			}
-
-			//TODO: set the policy bean
-			//dynamicProperties.setPolicyBean();
 		}
 
 		//if fist message - setup the sequence for the client side
@@ -277,85 +265,53 @@
 			throw new SandeshaException(
 					"Invalid SOAP message. Body is not present");
 
-		//TODO - Is this a correct way to find out validity of app.
-		// messages.
-		boolean validAppMessage = false;
-		if (soapBody.getChildElements().hasNext())
-			validAppMessage = true;
-
-		if (validAppMessage) {
-
-			//valid response
-
-			//Changing message Id.
-			//TODO remove this when Axis2 start sending uuids as uuid:xxxx
-			String messageId1 = SandeshaUtil.getUUID();
-			if (rmMsgCtx.getMessageId() == null) {
-				rmMsgCtx.setMessageId(messageId1);
-			}
+		String messageId1 = SandeshaUtil.getUUID();
+		if (rmMsgCtx.getMessageId() == null) {
+			rmMsgCtx.setMessageId(messageId1);
+		}
 
-			if (serverSide) {
+		if (serverSide) {
 
-				//processing the response
-				processResponseMessage(rmMsgCtx, internalSequenceId,
-						messageNumber);
-
-				MessageContext reqMsgCtx = msgCtx
-						.getOperationContext()
-						.getMessageContext(WSDLConstants.MESSAGE_LABEL_IN_VALUE);
-				RMMsgContext requestRMMsgCtx = MsgInitializer
-						.initializeMessage(reqMsgCtx);
-
-				//let the request end with 202 if a ack has not been
-				// written in the incoming thread.
-				if (reqMsgCtx.getProperty(Constants.ACK_WRITTEN) == null
-						|| !"true".equals(reqMsgCtx
-								.getProperty(Constants.ACK_WRITTEN)))
-					reqMsgCtx.getOperationContext().setProperty(
-							org.apache.axis2.Constants.RESPONSE_WRITTEN,
-							"false");
-			} else {
-
-				//setting reply to FIXME
-				//msgCtx.setReplyTo(new EndpointReference
-				// ("http://localhost:9070/somethingWorking"));
-
-				//Setting WSA Action if null
-				//TODO: Recheck weather this actions are correct
-				EndpointReference toEPR = msgCtx.getTo();
-
-				if (toEPR == null)
-					throw new SandeshaException("To EPR is not found");
-
-				String to = toEPR.getAddress();
-				String operationName = msgCtx.getOperationContext()
-						.getAxisOperation().getName().getLocalPart();
+			//processing the response
+			processResponseMessage(rmMsgCtx, internalSequenceId, messageNumber);
 
-				if (msgCtx.getWSAAction() == null) {
-					msgCtx.setWSAAction(to + "/" + operationName);
-				}
+			MessageContext reqMsgCtx = msgCtx.getOperationContext()
+					.getMessageContext(WSDLConstants.MESSAGE_LABEL_IN_VALUE);
+			RMMsgContext requestRMMsgCtx = MsgInitializer
+					.initializeMessage(reqMsgCtx);
 
-				if (msgCtx.getSoapAction() == null) {
-					msgCtx
-							.setSoapAction("\"" + to + "/" + operationName
-									+ "\"");
-				}
+			//let the request end with 202 if a ack has not been
+			// written in the incoming thread.
+			if (reqMsgCtx.getProperty(Constants.ACK_WRITTEN) == null
+					|| !"true".equals(reqMsgCtx
+							.getProperty(Constants.ACK_WRITTEN)))
+				reqMsgCtx.getOperationContext().setProperty(
+						org.apache.axis2.Constants.RESPONSE_WRITTEN, "false");
+		} else {
+			EndpointReference toEPR = msgCtx.getTo();
+
+			if (toEPR == null)
+				throw new SandeshaException("To EPR is not found");
 
-				//processing the response
-				processResponseMessage(rmMsgCtx, internalSequenceId, messageNumber);
+			String to = toEPR.getAddress();
+			String operationName = msgCtx.getOperationContext()
+					.getAxisOperation().getName().getLocalPart();
 
+			if (msgCtx.getWSAAction() == null) {
+				msgCtx.setWSAAction(to + "/" + operationName);
 			}
 
-			//pausing the message
-			msgCtx.setPausedTrue(getName());
-		}
+			if (msgCtx.getSoapAction() == null) {
+				msgCtx.setSoapAction("\"" + to + "/" + operationName + "\"");
+			}
 
-		//		}catch (Exception e) {
-		//			e.getStackTrace();
-		//			throw new AxisFault ("Sandesha got an exception. See logs for
-		// details");
-		//		}
+			//processing the response
+			processResponseMessage(rmMsgCtx, internalSequenceId, messageNumber);
 
+		}
+
+		//pausing the message
+		msgCtx.setPausedTrue(getName());
 	}
 
 	public void addCreateSequenceMessage(RMMsgContext applicationRMMsg,
@@ -399,11 +355,6 @@
 		}
 
 		MessageContext createSeqMsg = createSeqRMMessage.getMessageContext();
-
-		//TODO remove below
-		//createSeqMsg.setReplyTo(new EndpointReference
-		// ("http://localhost:9070/somethingWorking"));
-
 		createSeqMsg.setRelatesTo(null); //create seq msg does not relateTo
 		// anything
 		AbstractContext context = applicationRMMsg.getContext();
@@ -433,11 +384,11 @@
 		createSeqEntry.setMessageId(createSeqRMMessage.getMessageId());
 		createSeqEntry.setSend(true);
 		retransmitterMgr.insert(createSeqEntry);
-
 	}
 
 	private void processResponseMessage(RMMsgContext rmMsg,
-			String internalSequenceId, long messageNumber) throws SandeshaException {
+			String internalSequenceId, long messageNumber)
+			throws SandeshaException {
 
 		MessageContext msg = rmMsg.getMessageContext();
 
@@ -466,12 +417,11 @@
 
 		//again - looks weird in the client side - but consistent
 		SequencePropertyBean outSequenceBean = sequencePropertyMgr.retrieve(
-				internalSequenceId, Constants.SequenceProperties.OUT_SEQUENCE_ID);
+				internalSequenceId,
+				Constants.SequenceProperties.OUT_SEQUENCE_ID);
 
 		if (toBean == null)
 			throw new SandeshaException("To is null");
-		//		if (replyToBean == null)
-		//			throw new SandeshaException("Replyto is null");
 
 		EndpointReference toEPR = (EndpointReference) toBean.getValue();
 		EndpointReference replyToEPR = null;
@@ -484,13 +434,6 @@
 				|| toEPR.getAddress() == "")
 			throw new SandeshaException("To Property has an invalid value");
 
-		//		if (replyToEPR == null || replyToEPR.getAddress() == null
-		//				|| replyToEPR.getAddress() == "")
-		//			throw new SandeshaException("ReplyTo is not set correctly");
-
-		//Setting wsa:To to the replyTo value of the respective request message
-		//(instead of the replyTo of the CreateSequenceMessage)
-
 		String newToStr = null;
 
 		if (msg.isServerSide()) {
@@ -543,8 +486,6 @@
 
 			if (requestSequence.getLastMessage() != null) {
 				lastMessage = true;
-				//FIXME - This fails if request last message has more than one
-				// responses.
 				sequence.setLastMessage(new LastMessage(factory));
 
 				//saving the last message no.
@@ -576,7 +517,6 @@
 
 		AckRequested ackRequested = null;
 
-		//TODO do this based on policies.
 		boolean addAckRequested = false;
 		if (!lastMessage)
 			addAckRequested = true;
@@ -587,13 +527,11 @@
 		String identifierStr = null;
 		if (outSequenceBean == null || outSequenceBean.getValue() == null) {
 			identifierStr = Constants.TEMP_SEQUENCE_ID;
-			//			identifier.setIndentifer(Constants.INTERNAL_SEQUENCE_ID);
-			//			sequence.setIdentifier(identifier);
 
 		} else {
 			identifierStr = (String) outSequenceBean.getValue();
-			//identifier.setIndentifer((String) outSequenceBean.getValue());
 		}
+
 		Identifier id1 = new Identifier(factory);
 		id1.setIndentifer(identifierStr);
 		sequence.setIdentifier(id1);
@@ -614,9 +552,6 @@
 			throw new SandeshaException(e1.getMessage());
 		}
 
-		//		//send the message through sender only in the server case.
-		//		//in the client case use the normal flow.
-		//		if (msg.isServerSide()) {
 		//Retransmitter bean entry for the application message
 		SenderBean appMsgEntry = new SenderBean();
 		String key = SandeshaUtil
@@ -633,12 +568,10 @@
 		}
 		appMsgEntry.setInternalSequenceId(internalSequenceId);
 		retransmitterMgr.insert(appMsgEntry);
-		//		}
 	}
 
 	private long getNextMsgNo(ConfigurationContext context,
 			String internalSequenceId) throws SandeshaException {
-		//FIXME set a correct message number.
 
 		StorageManager storageManager = SandeshaUtil
 				.getSandeshaStorageManager(context);

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=349710&r1=349709&r2=349710&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 03:32:54 2005
@@ -98,7 +98,6 @@
 		Collection retransmitterEntriesOfSequence = retransmitterMgr
 				.find(input);
 
-		//TODO - make following more efficient
 		while (ackRangeIterator.hasNext()) {
 			AcknowledgementRange ackRange = (AcknowledgementRange) ackRangeIterator
 					.next();
@@ -113,7 +112,6 @@
 			}
 		}
 
-		//TODO - make following more efficient
 		while (nackIterator.hasNext()) {
 			Nack nack = (Nack) nackIterator.next();
 			long msgNo = nack.getNackNumber();
@@ -151,9 +149,6 @@
 			rmMsgCtx.getMessageContext().setPausedTrue(
 					new QName(Constants.IN_HANDLER_NAME));
 		}
-
-		int i = 1;
-
 	}
 
 	private SenderBean getRetransmitterEntry(Collection collection,
@@ -191,8 +186,6 @@
 		RMMsgContext terminateRMMessage = RMMsgCreator
 				.createTerminateSequenceMessage(incomingAckRMMsg, outSequenceId);
 
-		//SequencePropertyBean replyToBean =
-		// seqPropMgr.retrieve(internalSequenceId,Constants.SequenceProperties.REPLY_TO_EPR);
 		SequencePropertyBean toBean = seqPropMgr.retrieve(internalSequenceId,
 				Constants.SequenceProperties.TO_EPR);
 
@@ -205,8 +198,6 @@
 				Constants.WSA.NS_URI_ANONYMOUS));
 		terminateRMMessage.setFaultTo(new EndpointReference(
 				Constants.WSA.NS_URI_ANONYMOUS));
-		//terminateRMMessage.setFrom(new EndpointReference
-		// (replyToEPR.getAddress()));
 		terminateRMMessage
 				.setWSAAction(Constants.WSRM.Actions.ACTION_TERMINATE_SEQUENCE);
 		terminateRMMessage
@@ -226,7 +217,6 @@
 		//Set a retransmitter lastSentTime so that terminate will be send with
 		// some delay.
 		//Otherwise this get send before return of the current request (ack).
-		//TODO verify that the time given is correct
 		terminateBean.setTimeToSend(System.currentTimeMillis()
 				+ Constants.TERMINATE_DELAY);
 

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=349710&r1=349709&r2=349710&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 03:32:54 2005
@@ -74,9 +74,6 @@
 
 	public void processMessage(RMMsgContext rmMsgCtx) throws SandeshaException {
 
-		//Object obj =
-		// rmMsgCtx.getProperty(Constants.APPLICATION_PROCESSING_DONE);
-
 		//Processing for ack if any
 		SequenceAcknowledgement sequenceAck = (SequenceAcknowledgement) rmMsgCtx
 				.getMessagePart(Constants.MessageParts.SEQ_ACKNOWLEDGEMENT);
@@ -125,10 +122,6 @@
 			//this is a duplicate message and the invocation type is
 			// EXACTLY_ONCE.
 
-			//throw new SandeshaException(
-			//		"Duplicate message - Invocation type is EXACTLY_ONCE");
-
-			//TODO is this enough
 			msgCtx.setPausedTrue(new QName(Constants.IN_HANDLER_NAME));
 
 		}
@@ -143,11 +136,7 @@
 
 		sendAckIfNeeded(rmMsgCtx, messagesStr);
 
-		//		} else {
-		//			//TODO Add async Ack
-		//		}
-
-		//		Pause the messages bean if not the right message to invoke.
+		//	Pause the messages bean if not the right message to invoke.
 		NextMsgBeanMgr mgr = storageManager.getNextMsgBeanMgr();
 		NextMsgBean bean = mgr.retrieve(sequenceId);
 
@@ -158,17 +147,12 @@
 
 		long nextMsgno = bean.getNextMsgNoToProcess();
 
-		//FIXME - fix delivery assurances for the client side
-
 		if (msgCtx.isServerSide()) {
 			boolean inOrderInvocation = PropertyManager.getInstance().isInOrderInvocation();
 			if (inOrderInvocation) {
 				//pause the message
 				msgCtx.setPausedTrue(new QName(Constants.IN_HANDLER_NAME));
 
-				//Adding an entry in the SequencesToInvoke List TODO - add this
-				// to
-				// a module init kind of place.
 				SequencePropertyBean incomingSequenceListBean = (SequencePropertyBean) seqPropMgr
 						.retrieve(
 								Constants.SequenceProperties.ALL_SEQUENCES,
@@ -186,7 +170,6 @@
 					seqPropMgr.insert(incomingSequenceListBean);
 				}
 
-				//This must be a List :D
 				ArrayList incomingSequenceList = (ArrayList) incomingSequenceListBean
 						.getValue();
 
@@ -218,9 +201,6 @@
 			}
 		}
 
-		//client side - SET CheckResponse to true.
-		//FIXME this will not work. Even in client side inServerSide () is true
-		// for the messages.
 		try {
 			MessageContext requestMessage = rmMsgCtx.getMessageContext()
 					.getOperationContext().getMessageContext(
@@ -237,9 +217,6 @@
 		} catch (AxisFault e) {
 			throw new SandeshaException(e.getMessage());
 		}
-
-		//SET THe RESPONSE
-
 	}
 
 	//TODO convert following from INT to LONG
@@ -281,7 +258,6 @@
 		LastMessage lastMessage = (LastMessage) sequence.getLastMessage();
 
 		//Setting the ack depending on AcksTo.
-		//TODO: Stop sending askc for every message.
 		SequencePropertyBean acksToBean = seqPropMgr.retrieve(sequenceId,
 				Constants.SequenceProperties.ACKS_TO_EPR);
 
@@ -292,8 +268,6 @@
 			throw new SandeshaException(
 					"Seqeunce properties are not set correctly");
 
-		//if (acksToStr.equals(Constants.WSA.NS_URI_ANONYMOUS)) {
-
 		if (Constants.WSA.NS_URI_ANONYMOUS.equals(acksTo.getAddress())) {
 			// send ack in the sync case, only if the last message or the
 			// ackRequested tag is present.
@@ -330,7 +304,7 @@
 
 		ackMsgCtx.setMessageID(SandeshaUtil.getUUID());
 
-		//Set new envelope
+		//Setting new envelope
 		SOAPEnvelope envelope = factory.getDefaultEnvelope();
 		try {
 			ackMsgCtx.setEnvelope(envelope);
@@ -347,7 +321,7 @@
 			AxisEngine engine = new AxisEngine(ackRMMsgCtx.getMessageContext()
 					.getSystemContext());
 
-			//set CONTEXT_WRITTEN since acksto is anonymous
+			//setting CONTEXT_WRITTEN since acksto is anonymous
 			if (rmMsgCtx.getMessageContext().getOperationContext() == null) {
 				//operation context will be null when doing in a GLOBAL
 				// handler.
@@ -373,8 +347,6 @@
 				throw new SandeshaException(e1.getMessage());
 			}
 		} else {
-			//rmMsgCtx.getMessageContext().getOperationContext().setProperty(
-			//	org.apache.axis2.Constants.RESPONSE_WRITTEN, "false");
 
 			SenderBeanMgr retransmitterBeanMgr = storageManager
 					.getRetransmitterBeanMgr();
@@ -389,7 +361,7 @@
 
 			//the internalSequenceId value of the retransmitter Table for the
 			// messages related to an incoming
-			//sequence is the actual sequence ID - TODO document this.
+			//sequence is the actual sequence ID
 			ackBean.setInternalSequenceId(sequenceId);
 
 			RMPolicyBean policyBean = (RMPolicyBean) rmMsgCtx

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=349710&r1=349709&r2=349710&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 03:32:54 2005
@@ -148,10 +148,6 @@
 			SequencePropertyBean seqPropBean = new SequencePropertyBean(
 					newSequenceId, Constants.SequenceProperties.ACKS_TO_EPR,
 					acksTo);
-			//		InMemorySequencePropertyBeanMgr beanMgr = new
-			// InMemorySequencePropertyBeanMgr
-			// (Constants.DEFAULT_STORAGE_TYPE);
-			//		beanMgr.create(seqPropBean);
 
 			StorageManager storageManager = SandeshaUtil
 					.getSandeshaStorageManager(context);
@@ -170,7 +166,6 @@
 					org.apache.axis2.Constants.RESPONSE_WRITTEN);
 			if (Constants.WSA.NS_URI_ANONYMOUS.equals(createSeqMsg.getReplyTo()
 					.getAddress())) {
-				//So that '202 OK' get sent instead of 200 OK.
 				createSeqMsg.getOperationContext().setProperty(
 						org.apache.axis2.Constants.RESPONSE_WRITTEN, "true");
 			} else {

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=349710&r1=349709&r2=349710&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 03:32:54 2005
@@ -194,8 +194,6 @@
 				.setProperty(org.apache.axis2.Constants.RESPONSE_WRITTEN,
 						"false");
 
-		//FIXME - Dont have to de below if the correct operation description is
-		// set.
 		createSeqResponseRMMsgCtx.getMessageContext().setPausedTrue(
 				new QName(Constants.IN_HANDLER_NAME));
 	}

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=349710&r1=349709&r2=349710&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 03:32:54 2005
@@ -106,14 +106,6 @@
 		this.key = key;
 	}
 
-//	public long getLastSentTime() {
-//		return LastSentTime;
-//	}
-//
-//	public void setLastSentTime(long lastSentTime) {
-//		LastSentTime = lastSentTime;
-//	}
-
 	public String getMessageId() {
 		return messageId;
 	}

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=349710&r1=349709&r2=349710&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 03:32:54 2005
@@ -36,9 +36,6 @@
 
 	private Hashtable table = null;
 
-	//TODO change the primary key.
-	//When offered. msgId==null
-
 	public InMemoryCreateSeqBeanMgr(AbstractContext context) {
 		Object obj = context.getProperty(Constants.BeanMAPs.CREATE_SEQUECE);
 		if (obj != null) {
@@ -79,13 +76,6 @@
 		CreateSeqBean temp;
 		while (iterator.hasNext()) {
 			temp = (CreateSeqBean) iterator.next();
-			//			if ((bean.getCreateSeqMsgId() != null && bean.getCreateSeqMsgId()
-			//					.equals(temp.getCreateSeqMsgId()))
-			//					&& (bean.getSequenceId() != null && bean.getSequenceId()
-			//							.equals(bean.getSequenceId()))) {
-			//				beans.add(temp);
-			//
-			//			}
 
 			boolean equal = true;
 

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=349710&r1=349709&r2=349710&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 03:32:54 2005
@@ -69,14 +69,7 @@
 		while (iterator.hasNext()) {
 			temp = (InvokerBean) iterator.next();
 			boolean select = true;
-			/*
-			 * if ((temp.getKey() != null &&
-			 * bean.getKey().equals(temp.getKey())) && (bean.getMsgNo() != -1 &&
-			 * bean.getMsgNo() == temp.getMsgNo()) && (bean.getSequenceId() !=
-			 * null && bean.getSequenceId().equals(temp.getSequenceId()))) {
-			 */
 
-			//}
 			if (bean.getKey() != null && !bean.getKey().equals(temp.getKey()))
 				select = false;
 

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=349710&r1=349709&r2=349710&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 03:32:54 2005
@@ -75,18 +75,6 @@
 		while (iterator.hasNext()) {
 			temp = (NextMsgBean) iterator.next();
 
-			//			if ((bean.getSequenceId() != null && bean.getSequenceId().equals(
-			//					temp.getSequenceId()))
-			//					/*
-			//					 * && (bean.getNextMsgNoToProcess() != null &&
-			//					 *
-			// bean.getNextMsgNoToProcess().equals(temp.getNextMsgNoToProcess()))
-			//					 */
-			//					&& (bean.getNextMsgNoToProcess() > 0)) {
-			//
-			//				beans.add(temp);
-			//			}
-
 			boolean equal = true;
 
 			if (bean.getNextMsgNoToProcess() > 0

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=349710&r1=349709&r2=349710&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 03:32:54 2005
@@ -148,8 +148,7 @@
 		if (!table.contains(bean))
 			return false;
 
-		return true; //No need to update. Being a reference does the job:)
-					 // //table.put(bean.getMessageId(), bean) != null;
+		return true; //No need to update. Being a reference does the job.
 	}
 
 }

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=349710&r1=349709&r2=349710&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 03:32:54 2005
@@ -74,16 +74,6 @@
 		while (iterator.hasNext()) {
 			temp = (SequencePropertyBean) iterator.next();
 
-			//			if ((bean.getSequenceId() != null && bean.getSequenceId().equals(
-			//					temp.getSequenceId()))
-			//					&& (bean.getName() != null && bean.getName().equals(
-			//							temp.getName()))
-			//					&& (bean.getValue() != null && bean.getValue().equals(
-			//							temp.getValue()))) {
-			//
-			//				beans.add(temp);
-			//			}
-
 			boolean equal = true;
 
 			if (bean.getSequenceId() != null

Modified: webservices/sandesha/trunk/src/org/apache/sandesha2/storage/inmemory/InMemoryStorageManager.java
URL: http://svn.apache.org/viewcvs/webservices/sandesha/trunk/src/org/apache/sandesha2/storage/inmemory/InMemoryStorageManager.java?rev=349710&r1=349709&r2=349710&view=diff
==============================================================================
--- webservices/sandesha/trunk/src/org/apache/sandesha2/storage/inmemory/InMemoryStorageManager.java (original)
+++ webservices/sandesha/trunk/src/org/apache/sandesha2/storage/inmemory/InMemoryStorageManager.java Tue Nov 29 03:32:54 2005
@@ -63,18 +63,6 @@
 		return new InMemoryInvokerBeanMgr(getContext());
 	}
 
-	//	public static StorageManager getBeanMgrFactory (int storageType)
-	// {
-	//		switch (storageType) {
-	//			case Constants.STORAGE_TYPE_PERSISTANCE:
-	//				return new PersistentBeanMgrFactory();
-	//			case Constants.STORAGE_TYPE_IN_MEMORY:
-	//				return new InMemBeanMgrFactory();
-	//			default:
-	//				return null;
-	//		}
-	//	}
-
 	public void init(ConfigurationContext context) {
 		setContext(context);
 	}

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=349710&r1=349709&r2=349710&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 03:32:54 2005
@@ -190,7 +190,6 @@
 							reason = "A sequence with offered sequenceId, already axists";
 						}
 
-						System.out.println("OutSequenceId:" + outSequenceId);
 					}
 				}
 			}
@@ -361,10 +360,8 @@
 				else
 					data.setCode(SOAP12Constants.FAULT_CODE_SENDER);
 
-				data
-						.setSubcode(Constants.SOAPFaults.Subcodes.INVALID_ACKNOWLEDGEMENT);
-				data
-						.setSubcode("The SequenceAcknowledgement is invalid. Lower value is larger than upper value");
+				data.setSubcode(Constants.SOAPFaults.Subcodes.INVALID_ACKNOWLEDGEMENT);
+				data.setSubcode("The SequenceAcknowledgement is invalid. Lower value is larger than upper value");
 				data.setDetail(sequenceAcknowledgement.getOMElement());
 
 				return getFault(rmMsgContext, data);
@@ -420,7 +417,6 @@
 			faultMsgContext.setAxisOperation(operation);
 			faultMsgContext.setOperationContext(operationContext);
 
-			//String toStr = null;
 			String acksToStr = null;
 			if (referenceRMMsgContext.getMessageType() == Constants.MessageTypes.CREATE_SEQ) {
 				CreateSequence createSequence = (CreateSequence) referenceRMMsgContext

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=349710&r1=349709&r2=349710&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 03:32:54 2005
@@ -19,7 +19,6 @@
 
 import org.apache.axis2.context.MessageContext;
 import org.apache.sandesha2.Constants;
-import org.apache.sandesha2.SandeshaDynamicProperties;
 import org.apache.sandesha2.policy.RMPolicyBean;
 import org.apache.sandesha2.storage.beans.SenderBean;
 
@@ -92,7 +91,6 @@
 		bean.setReSend(false);
 	}
 
-	//TODO: Have to change this to be plugable
 	private long generateNextExponentialBackedoffDifference(int count,
 			long initialInterval) {
 		long interval = initialInterval;

Modified: webservices/sandesha/trunk/src/org/apache/sandesha2/util/MsgInitializer.java
URL: http://svn.apache.org/viewcvs/webservices/sandesha/trunk/src/org/apache/sandesha2/util/MsgInitializer.java?rev=349710&r1=349709&r2=349710&view=diff
==============================================================================
--- webservices/sandesha/trunk/src/org/apache/sandesha2/util/MsgInitializer.java (original)
+++ webservices/sandesha/trunk/src/org/apache/sandesha2/util/MsgInitializer.java Tue Nov 29 03:32:54 2005
@@ -47,7 +47,6 @@
 	 */
 	private static void populateRMMsgContext(MessageContext msgCtx,
 			RMMsgContext rmMsgContext) {
-		//TODO set message parts
 
 		RMElements elements = new RMElements();
 		elements.fromSOAPEnvelope(msgCtx.getEnvelope());
@@ -90,8 +89,6 @@
 	 */
 	private static boolean validateMessage(RMMsgContext rmMsgCtx)
 			throws SandeshaException {
-
-		//TODO: performa validation
 
 		//Setting message type.
 		if (rmMsgCtx.getMessagePart(Constants.MessageParts.CREATE_SEQ) != null)

Modified: webservices/sandesha/trunk/src/org/apache/sandesha2/util/PropertyManager.java
URL: http://svn.apache.org/viewcvs/webservices/sandesha/trunk/src/org/apache/sandesha2/util/PropertyManager.java?rev=349710&r1=349709&r2=349710&view=diff
==============================================================================
--- webservices/sandesha/trunk/src/org/apache/sandesha2/util/PropertyManager.java (original)
+++ webservices/sandesha/trunk/src/org/apache/sandesha2/util/PropertyManager.java Tue Nov 29 03:32:54 2005
@@ -49,7 +49,6 @@
 			
 			Properties properties = new Properties ();
 			if (in!=null) {
-				//throw new IOException ("sandesha2 property file not found");
 				properties.load(in);
 			}
 			

Modified: webservices/sandesha/trunk/src/org/apache/sandesha2/util/RMMsgCreator.java
URL: http://svn.apache.org/viewcvs/webservices/sandesha/trunk/src/org/apache/sandesha2/util/RMMsgCreator.java?rev=349710&r1=349709&r2=349710&view=diff
==============================================================================
--- webservices/sandesha/trunk/src/org/apache/sandesha2/util/RMMsgCreator.java (original)
+++ webservices/sandesha/trunk/src/org/apache/sandesha2/util/RMMsgCreator.java Tue Nov 29 03:32:54 2005
@@ -156,7 +156,6 @@
 			}
 		}
 
-		//TODO decide - where to send create seq. Acksto or replyTo
 		SequencePropertyBean replyToBean = seqPropMgr.retrieve(internalSequenceId,
 				Constants.SequenceProperties.REPLY_TO_EPR);
 		SequencePropertyBean toBean = seqPropMgr.retrieve(internalSequenceId,
@@ -183,7 +182,6 @@
 		if (replyToEPR != null)
 			createSeqRMMsg.setReplyTo(replyToEPR);
 
-		//FIXME - Give user a seperate way to set acksTo (client side)
 		createSequencePart.setAcksTo(new AcksTo(
 				new Address(acksToEPR, factory), factory));
 
@@ -305,7 +303,6 @@
 		if (offer != null) {
 			String outSequenceId = offer.getIdentifer().getIdentifier();
 
-			//TODO do a better validation for the offered out sequence id.
 			if (outSequenceId != null && !"".equals(outSequenceId)) {
 
 				Accept accept = new Accept(factory);

Modified: webservices/sandesha/trunk/src/org/apache/sandesha2/util/SandeshaUtil.java
URL: http://svn.apache.org/viewcvs/webservices/sandesha/trunk/src/org/apache/sandesha2/util/SandeshaUtil.java?rev=349710&r1=349709&r2=349710&view=diff
==============================================================================
--- webservices/sandesha/trunk/src/org/apache/sandesha2/util/SandeshaUtil.java (original)
+++ webservices/sandesha/trunk/src/org/apache/sandesha2/util/SandeshaUtil.java Tue Nov 29 03:32:54 2005
@@ -55,7 +55,6 @@
 import org.apache.axis2.util.Utils;
 import org.apache.sandesha2.Constants;
 import org.apache.sandesha2.RMMsgContext;
-import org.apache.sandesha2.SandeshaDynamicProperties;
 import org.apache.sandesha2.SandeshaException;
 import org.apache.sandesha2.storage.StorageManager;
 import org.apache.sandesha2.workers.InOrderInvoker;
@@ -78,8 +77,6 @@
 
 	private static InOrderInvoker invoker = new InOrderInvoker();
 
-	private static SandeshaDynamicProperties dynamicProperties = null;
-
 	/**
 	 * Create a new UUID.
 	 * 
@@ -223,14 +220,12 @@
 	public static void startSenderIfStopped(ConfigurationContext context) {
 		if (!sender.isSenderStarted()) {
 			sender.start(context);
-			System.out.println("Sender started....");
 		}
 	}
 
 	public static void startInvokerIfStopped(ConfigurationContext context) {
 		if (!invoker.isInvokerStarted()) {
 			invoker.start(context);
-			System.out.println("Invoker started....");
 		}
 	}
 
@@ -277,8 +272,6 @@
 				throw new AxisFault(Messages.getMessage("inputstreamNull"));
 			}
 
-			//This should be set later
-			//TODO check weather this affects MTOM
 			String contentType = null;
 
 			StAXBuilder builder = null;
@@ -415,21 +408,6 @@
 		}
 	}
 
-	public static SandeshaDynamicProperties getDynamicProperties() {
-		if (dynamicProperties == null) {
-			loadDymanicProperties();
-		}
-
-		return dynamicProperties;
-	}
-
-	private static void loadDymanicProperties() {
-		dynamicProperties = new SandeshaDynamicProperties();
-
-		//TODO: override properties from the sandesha-config.xml
-
-	}
-
 	public static int getSOAPVersion(SOAPEnvelope envelope)
 			throws SandeshaException {
 		String namespaceName = envelope.getNamespace().getName();
@@ -531,22 +509,6 @@
 
 			newMessageContext.setAxisOperation(operation);
 
-//			if (referenceMessage.getServiceGroupContext() != null) {
-//				newMessageContext.setServiceGroupContext(referenceMessage
-//						.getServiceGroupContext());
-//				newMessageContext.setServiceGroupContextId(referenceMessage
-//						.getServiceGroupContextId());
-//			}
-//
-//			if (referenceMessage.getServiceContext() != null) {
-//				newMessageContext.setServiceContext(referenceMessage
-//						.getServiceContext());
-//				newMessageContext.setServiceContextID(referenceMessage
-//						.getServiceContextID());
-//			} else {
-//				
-//			}
-
 			OperationContext operationContext = new OperationContext(operation);
 			newMessageContext.setOperationContext(operationContext);
 			operationContext.addMessageContext(newMessageContext);
@@ -561,7 +523,7 @@
 			newMessageContext.setTransportOut(referenceMessage
 					.getTransportOut());
 
-			//copying transport info. TODO remove http specific ness.
+			//copying transport info.
 			newMessageContext.setProperty(MessageContext.TRANSPORT_OUT,
 					referenceMessage.getProperty(MessageContext.TRANSPORT_OUT));
 			newMessageContext.setProperty(HTTPConstants.HTTPOutTransportInfo,

Modified: webservices/sandesha/trunk/src/org/apache/sandesha2/util/SequenceManager.java
URL: http://svn.apache.org/viewcvs/webservices/sandesha/trunk/src/org/apache/sandesha2/util/SequenceManager.java?rev=349710&r1=349709&r2=349710&view=diff
==============================================================================
--- webservices/sandesha/trunk/src/org/apache/sandesha2/util/SequenceManager.java (original)
+++ webservices/sandesha/trunk/src/org/apache/sandesha2/util/SequenceManager.java Tue Nov 29 03:32:54 2005
@@ -30,12 +30,6 @@
 
 	public static String setupNewSequence(RMMsgContext createSequenceMsg)
 			throws AxisFault {
-		//		SequencePropertyBean seqPropBean = new SequencePropertyBean
-		// (sequenceId,Constants.SEQ_PROPERTY_RECEIVED_MESSAGES,"");
-		//		InMemorySequencePropertyBeanMgr beanMgr = new
-		// InMemorySequencePropertyBeanMgr
-		// (Constants.DEFAULT_STORAGE_TYPE);
-		//		beanMgr.create(seqPropBean);
 
 		String sequenceId = SandeshaUtil.getUUID();
 		AbstractContext context = createSequenceMsg.getContext();
@@ -72,9 +66,6 @@
 		SequencePropertyBeanMgr seqPropMgr = storageManager
 				.getSequencePropretyBeanMgr();
 
-		//TODO - recheck following
-		//incoming To - reply address of response messages
-		//imcoming replyTo - to address of response messages
 		SequencePropertyBean receivedMsgBean = new SequencePropertyBean(
 				sequenceId, Constants.SequenceProperties.RECEIVED_MESSAGES, "");
 		SequencePropertyBean toBean = new SequencePropertyBean(sequenceId,
@@ -133,11 +124,6 @@
 		SequencePropertyBean acksToBean = new SequencePropertyBean(
 				iternalSequenceId, Constants.SequenceProperties.ACKS_TO_EPR,
 				acksToEPR);
-
-		//		//TODO - make default for replyTo anonymous
-		//		if (replyToEPR==null)
-		//			replyToEPR = new EndpointReference (Constants.WSA.NS_URI_ANONYMOUS);
-
 		seqPropMgr.insert(toBean);
 		seqPropMgr.insert(acksToBean);
 



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