You are viewing a plain text version of this content. The canonical link for it is here.
Posted to axis-cvs@ws.apache.org by gd...@apache.org on 2007/03/04 19:17:07 UTC

svn commit: r514453 [11/26] - in /webservices/axis2/trunk/java/modules/kernel: src/org/apache/axis2/ src/org/apache/axis2/addressing/ src/org/apache/axis2/addressing/wsdl/ src/org/apache/axis2/builder/ src/org/apache/axis2/client/ src/org/apache/axis2/...

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/engine/AxisEngine.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/engine/AxisEngine.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/engine/AxisEngine.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/engine/AxisEngine.java Sun Mar  4 10:16:54 2007
@@ -57,7 +57,7 @@
     private static boolean NOT_RESUMING_EXECUTION = false;
     private static boolean IS_INBOUND = true;
     private static boolean IS_OUTBOUND = false;
-        
+
     /**
      * Constructor AxisEngine
      */
@@ -104,9 +104,9 @@
                         // TODO: should we be using a prefix on the faultcode?  What about
                         // the QName object Constants.FAULT_SOAP12_MUSTUNDERSTAND?
                         throw new AxisFault(Messages.getMessage(
-                                        "mustunderstandfailed",
-                                        prefix, SOAP12Constants.FAULT_CODE_MUST_UNDERSTAND),
-                                        SOAP12Constants.FAULT_CODE_MUST_UNDERSTAND);
+                                "mustunderstandfailed",
+                                prefix, SOAP12Constants.FAULT_CODE_MUST_UNDERSTAND),
+                                            SOAP12Constants.FAULT_CODE_MUST_UNDERSTAND);
                     }
                 } else {
                     // TODO: should we be using a prefix on the faultcode?  What about
@@ -114,7 +114,7 @@
                     throw new AxisFault(Messages.getMessage(
                             "mustunderstandfailed",
                             prefix, SOAP12Constants.FAULT_CODE_MUST_UNDERSTAND),
-                            SOAP12Constants.FAULT_CODE_MUST_UNDERSTAND);
+                                        SOAP12Constants.FAULT_CODE_MUST_UNDERSTAND);
                 }
             } else {
 
@@ -126,7 +126,7 @@
                     throw new AxisFault(Messages.getMessage(
                             "mustunderstandfailed",
                             prefix, SOAP11Constants.FAULT_CODE_MUST_UNDERSTAND),
-                            SOAP11Constants.FAULT_CODE_MUST_UNDERSTAND);
+                                        SOAP11Constants.FAULT_CODE_MUST_UNDERSTAND);
                 }
             }
         }
@@ -143,7 +143,7 @@
             throws AxisFault {
         return MessageContextBuilder.createFaultMessageContext(processingContext, e);
     }
-   
+
     /**
      * This methods represents the inflow of the Axis, this could be either at the server side or the client side.
      * Here the <code>ExecutionChain</code> is created using the Phases. The Handlers at the each Phases is ordered in
@@ -155,8 +155,8 @@
      * @see Handler
      */
     public InvocationResponse receive(MessageContext msgContext) throws AxisFault {
-        if(LoggingControl.debugLoggingAllowed && log.isTraceEnabled()){
-            log.trace(msgContext.getLogIDString()+" receive:"+msgContext.getMessageID());
+        if (LoggingControl.debugLoggingAllowed && log.isTraceEnabled()) {
+            log.trace(msgContext.getLogIDString() + " receive:" + msgContext.getMessageID());
         }
         ConfigurationContext confContext = msgContext.getConfigurationContext();
         ArrayList preCalculatedPhases =
@@ -167,38 +167,39 @@
         msgContext.setExecutionChain((ArrayList) preCalculatedPhases.clone());
         msgContext.setFLOW(MessageContext.IN_FLOW);
         try {
-          InvocationResponse pi = invoke(msgContext, IS_INBOUND, NOT_RESUMING_EXECUTION);
+            InvocationResponse pi = invoke(msgContext, IS_INBOUND, NOT_RESUMING_EXECUTION);
 
             if (pi.equals(InvocationResponse.CONTINUE)) {
                 if (msgContext.isServerSide()) {
-              // invoke the Message Receivers
-              checkMustUnderstand(msgContext);
-              
-              MessageReceiver receiver = msgContext.getAxisOperation().getMessageReceiver();
-              if (receiver==null){
-                  throw new AxisFault(Messages.getMessage(
-                          "nomessagereciever",
-                          msgContext.getAxisOperation().getName().toString()));
-              }
-              receiver.receive(msgContext);
-            }
-            flowComplete(msgContext, true);
+                    // invoke the Message Receivers
+                    checkMustUnderstand(msgContext);
+
+                    MessageReceiver receiver = msgContext.getAxisOperation().getMessageReceiver();
+                    if (receiver == null) {
+                        throw new AxisFault(Messages.getMessage(
+                                "nomessagereciever",
+                                msgContext.getAxisOperation().getName().toString()));
+                    }
+                    receiver.receive(msgContext);
+                }
+                flowComplete(msgContext, true);
             } else if (pi.equals(InvocationResponse.SUSPEND)) {
-            return pi;
+                return pi;
             } else if (pi.equals(InvocationResponse.ABORT)) {
-            flowComplete(msgContext, true);
-            return pi;
+                flowComplete(msgContext, true);
+                return pi;
             } else {
-            String errorMsg = "Unrecognized InvocationResponse encountered in AxisEngine.receive()";
-            log.error(msgContext.getLogIDString()+" "+errorMsg);
-            throw new AxisFault(errorMsg);
-          }
+                String errorMsg =
+                        "Unrecognized InvocationResponse encountered in AxisEngine.receive()";
+                log.error(msgContext.getLogIDString() + " " + errorMsg);
+                throw new AxisFault(errorMsg);
+            }
         }
         catch (AxisFault e) {
-          flowComplete(msgContext, true);
-          throw e;
+            flowComplete(msgContext, true);
+            throw e;
         }
-        
+
         return InvocationResponse.CONTINUE;
     }
 
@@ -208,85 +209,87 @@
      * if the msgContext is pauesd then the execution will be breaked
      *
      * @param msgContext
-     * @return An InvocationResponse that indicates what 
+     * @return An InvocationResponse that indicates what
      *         the next step in the message processing should be.
      * @throws AxisFault
      */
-    public InvocationResponse invoke(MessageContext msgContext, boolean inbound, boolean resuming) throws AxisFault {
+    public InvocationResponse invoke(MessageContext msgContext, boolean inbound, boolean resuming)
+            throws AxisFault {
 
         if (msgContext.getCurrentHandlerIndex() == -1) {
             msgContext.setCurrentHandlerIndex(0);
         }
 
         InvocationResponse pi = InvocationResponse.CONTINUE;
-        
+
         while (msgContext.getCurrentHandlerIndex() < msgContext.getExecutionChain().size()) {
             Handler currentHandler = (Handler) msgContext.getExecutionChain().
                     get(msgContext.getCurrentHandlerIndex());
-                        
+
             try {
                 if (!resuming) {
                     if (inbound) {
-                  msgContext.addInboundExecutedPhase(currentHandler);
+                        msgContext.addInboundExecutedPhase(currentHandler);
                     } else {
-                  msgContext.addOutboundExecutedPhase(currentHandler);
-                }
+                        msgContext.addOutboundExecutedPhase(currentHandler);
+                    }
                 } else {
-                /* If we are resuming the flow, we don't want to add the phase 
-                 * again, as it has already been added.
-                 */
-                resuming = false;
-              }
-              pi = currentHandler.invoke(msgContext);
+                    /* If we are resuming the flow, we don't want to add the phase
+                    * again, as it has already been added.
+                    */
+                    resuming = false;
+                }
+                pi = currentHandler.invoke(msgContext);
             }
             catch (AxisFault e) {
                 if (msgContext.getCurrentPhaseIndex() == 0) {
-                /* If we got a fault, we still want to add the phase to the
-                 list to be executed for flowComplete(...) unless this was
-                 the first handler, as then the currentPhaseIndex will be
-                 set to 0 and this will look like we've executed all of the
-                 handlers.  If, at some point, a phase really needs to get
-                 notification of flowComplete, then we'll need to introduce
-                 some more complex logic to keep track of what has been
-                 executed.*/ 
+                    /* If we got a fault, we still want to add the phase to the
+                    list to be executed for flowComplete(...) unless this was
+                    the first handler, as then the currentPhaseIndex will be
+                    set to 0 and this will look like we've executed all of the
+                    handlers.  If, at some point, a phase really needs to get
+                    notification of flowComplete, then we'll need to introduce
+                    some more complex logic to keep track of what has been
+                    executed.*/
                     if (inbound) {
-                  msgContext.removeFirstInboundExecutedPhase();
+                        msgContext.removeFirstInboundExecutedPhase();
                     } else {
-                  msgContext.removeFirstOutboundExecutedPhase();
+                        msgContext.removeFirstOutboundExecutedPhase();
+                    }
                 }
-              }
-              throw e;
+                throw e;
             }
 
             if (pi.equals(InvocationResponse.SUSPEND) ||
                     pi.equals(InvocationResponse.ABORT)) {
-              break;
+                break;
             }
 
             msgContext.setCurrentHandlerIndex(msgContext.getCurrentHandlerIndex() + 1);
         }
-        
+
         return pi;
     }
 
     private void flowComplete(MessageContext msgContext, boolean inbound) {
-      Iterator invokedPhaseIterator = inbound?msgContext.getInboundExecutedPhases():msgContext.getOutboundExecutedPhases(); 
-      
-      Handler currentHandler;
+        Iterator invokedPhaseIterator = inbound ? msgContext.getInboundExecutedPhases() :
+                msgContext.getOutboundExecutedPhases();
+
+        Handler currentHandler;
         while (invokedPhaseIterator.hasNext()) {
-        currentHandler = ((Handler)invokedPhaseIterator.next());
-        currentHandler.flowComplete(msgContext);
-      }
-          
-      /*This is needed because the OutInAxisOperation currently invokes
-       * receive() even when a fault occurs, and we will have already executed
-       * the flowComplete on those before receiveFault() is called.
-       */
+            currentHandler = ((Handler) invokedPhaseIterator.next());
+            currentHandler.flowComplete(msgContext);
+        }
+
+        /*This is needed because the OutInAxisOperation currently invokes
+        * receive() even when a fault occurs, and we will have already executed
+        * the flowComplete on those before receiveFault() is called.
+        */
         if (inbound) {
-        msgContext.resetInboundExecutedPhases();
+            msgContext.resetInboundExecutedPhases();
         } else {
-        msgContext.resetOutboundExecutedPhases();
-      }
+            msgContext.resetOutboundExecutedPhases();
+        }
     }
 
     /**
@@ -299,35 +302,35 @@
      * @throws AxisFault
      */
     public InvocationResponse resumeReceive(MessageContext msgContext) throws AxisFault {
-        if(LoggingControl.debugLoggingAllowed && log.isTraceEnabled()){
-            log.trace(msgContext.getLogIDString()+" resumeReceive:"+msgContext.getMessageID());
+        if (LoggingControl.debugLoggingAllowed && log.isTraceEnabled()) {
+            log.trace(msgContext.getLogIDString() + " resumeReceive:" + msgContext.getMessageID());
         }
 
-      //REVIEW: This name is a little misleading, as it seems to indicate that there should be a resumeReceiveFault as well, when, in fact, this does both 
-      //REVIEW: Unlike with receive, there is no wrapping try/catch clause which would
-      //fire off the flowComplete on an error, as we have to assume that the
-      //message will be resumed again, but perhaps we need to unwind back to
-      //the point at which the message was resumed and provide another API
-      //to allow the full unwind if the message is going to be discarded.
+        //REVIEW: This name is a little misleading, as it seems to indicate that there should be a resumeReceiveFault as well, when, in fact, this does both
+        //REVIEW: Unlike with receive, there is no wrapping try/catch clause which would
+        //fire off the flowComplete on an error, as we have to assume that the
+        //message will be resumed again, but perhaps we need to unwind back to
+        //the point at which the message was resumed and provide another API
+        //to allow the full unwind if the message is going to be discarded.
         //invoke the phases
         InvocationResponse pi = invoke(msgContext, IS_INBOUND, RESUMING_EXECUTION);
         //invoking the MR
-        
+
         if (pi.equals(InvocationResponse.CONTINUE)) {
             if (msgContext.isServerSide()) {
-            // invoke the Message Receivers
-            checkMustUnderstand(msgContext);
-            MessageReceiver receiver = msgContext.getAxisOperation().getMessageReceiver();
-            if (receiver==null){
-                throw new AxisFault(Messages.getMessage(
-                        "nomessagereciever",
-                        msgContext.getAxisOperation().getName().toString()));
-            }
-            receiver.receive(msgContext);
-          }
-          flowComplete(msgContext, true);
+                // invoke the Message Receivers
+                checkMustUnderstand(msgContext);
+                MessageReceiver receiver = msgContext.getAxisOperation().getMessageReceiver();
+                if (receiver == null) {
+                    throw new AxisFault(Messages.getMessage(
+                            "nomessagereciever",
+                            msgContext.getAxisOperation().getName().toString()));
+                }
+                receiver.receive(msgContext);
+            }
+            flowComplete(msgContext, true);
         }
-        
+
         return pi;
     }
 
@@ -341,16 +344,16 @@
      * @throws AxisFault
      */
     public InvocationResponse resumeSend(MessageContext msgContext) throws AxisFault {
-        if(LoggingControl.debugLoggingAllowed && log.isTraceEnabled()){
-            log.trace(msgContext.getLogIDString()+" resumeSend:"+msgContext.getMessageID());
+        if (LoggingControl.debugLoggingAllowed && log.isTraceEnabled()) {
+            log.trace(msgContext.getLogIDString() + " resumeSend:" + msgContext.getMessageID());
         }
 
-      //REVIEW: This name is a little misleading, as it seems to indicate that there should be a resumeSendFault as well, when, in fact, this does both 
-      //REVIEW: Unlike with send, there is no wrapping try/catch clause which would
-      //fire off the flowComplete on an error, as we have to assume that the
-      //message will be resumed again, but perhaps we need to unwind back to
-      //the point at which the message was resumed and provide another API
-      //to allow the full unwind if the message is going to be discarded.
+        //REVIEW: This name is a little misleading, as it seems to indicate that there should be a resumeSendFault as well, when, in fact, this does both
+        //REVIEW: Unlike with send, there is no wrapping try/catch clause which would
+        //fire off the flowComplete on an error, as we have to assume that the
+        //message will be resumed again, but perhaps we need to unwind back to
+        //the point at which the message was resumed and provide another API
+        //to allow the full unwind if the message is going to be discarded.
         //invoke the phases
         InvocationResponse pi = invoke(msgContext, IS_OUTBOUND, RESUMING_EXECUTION);
         //Invoking Transport Sender
@@ -361,7 +364,7 @@
             sender.invoke(msgContext);
             flowComplete(msgContext, false);
         }
-        
+
         return pi;
     }
 
@@ -373,9 +376,10 @@
      * @throws AxisFault
      */
     public InvocationResponse receiveFault(MessageContext msgContext) throws AxisFault {
-        if(LoggingControl.debugLoggingAllowed && log.isDebugEnabled()) {
-            log.debug(msgContext.getLogIDString()+" "+Messages.getMessage("receivederrormessage",
-                    msgContext.getMessageID()));
+        if (LoggingControl.debugLoggingAllowed && log.isDebugEnabled()) {
+            log.debug(
+                    msgContext.getLogIDString() + " " + Messages.getMessage("receivederrormessage",
+                                                                            msgContext.getMessageID()));
         }
         ConfigurationContext confContext = msgContext.getConfigurationContext();
         ArrayList preCalculatedPhases =
@@ -385,36 +389,37 @@
         // affecting later messages.
         msgContext.setExecutionChain((ArrayList) preCalculatedPhases.clone());
         msgContext.setFLOW(MessageContext.IN_FAULT_FLOW);
-        
+
         try {
-          InvocationResponse pi = invoke(msgContext, IS_INBOUND, NOT_RESUMING_EXECUTION);
+            InvocationResponse pi = invoke(msgContext, IS_INBOUND, NOT_RESUMING_EXECUTION);
 
             if (pi.equals(InvocationResponse.CONTINUE)) {
                 if (msgContext.isServerSide()) {
-              // invoke the Message Receivers
-              checkMustUnderstand(msgContext);
-              
-              MessageReceiver receiver = msgContext.getAxisOperation().getMessageReceiver();
+                    // invoke the Message Receivers
+                    checkMustUnderstand(msgContext);
 
-              receiver.receive(msgContext);
-            }
-            flowComplete(msgContext, true);
+                    MessageReceiver receiver = msgContext.getAxisOperation().getMessageReceiver();
+
+                    receiver.receive(msgContext);
+                }
+                flowComplete(msgContext, true);
             } else if (pi.equals(InvocationResponse.SUSPEND)) {
-            return pi;
+                return pi;
             } else if (pi.equals(InvocationResponse.ABORT)) {
-            flowComplete(msgContext, true);
-            return pi;
+                flowComplete(msgContext, true);
+                return pi;
             } else {
-            String errorMsg = "Unrecognized InvocationResponse encountered in AxisEngine.receiveFault()";
-            log.error(msgContext.getLogIDString()+" "+errorMsg);
-            throw new AxisFault(errorMsg);
-          }
+                String errorMsg =
+                        "Unrecognized InvocationResponse encountered in AxisEngine.receiveFault()";
+                log.error(msgContext.getLogIDString() + " " + errorMsg);
+                throw new AxisFault(errorMsg);
+            }
         }
         catch (AxisFault e) {
-          flowComplete(msgContext, true);
-          throw e;
+            flowComplete(msgContext, true);
+            throw e;
         }
-        
+
         return InvocationResponse.CONTINUE;
     }
 
@@ -427,8 +432,8 @@
      * @throws AxisFault
      */
     public InvocationResponse resume(MessageContext msgctx) throws AxisFault {
-        if(LoggingControl.debugLoggingAllowed && log.isTraceEnabled()){
-            log.trace(msgctx.getLogIDString()+" resume:"+msgctx.getMessageID());
+        if (LoggingControl.debugLoggingAllowed && log.isTraceEnabled()) {
+            log.trace(msgctx.getLogIDString() + " resume:" + msgctx.getMessageID());
         }
 
         msgctx.setPaused(false);
@@ -451,8 +456,8 @@
      * @see Handler
      */
     public void send(MessageContext msgContext) throws AxisFault {
-        if(LoggingControl.debugLoggingAllowed && log.isTraceEnabled()){
-            log.trace(msgContext.getLogIDString()+" send:"+msgContext.getMessageID());
+        if (LoggingControl.debugLoggingAllowed && log.isTraceEnabled()) {
+            log.trace(msgContext.getLogIDString() + " send:" + msgContext.getMessageID());
         }
         // find and invoke the Phases
         OperationContext operationContext = msgContext.getOperationContext();
@@ -465,40 +470,42 @@
         msgContext.setExecutionChain(outPhases);
         msgContext.setFLOW(MessageContext.OUT_FLOW);
         try {
-          InvocationResponse pi = invoke(msgContext, IS_OUTBOUND, NOT_RESUMING_EXECUTION);
+            InvocationResponse pi = invoke(msgContext, IS_OUTBOUND, NOT_RESUMING_EXECUTION);
 
             if (pi.equals(InvocationResponse.CONTINUE)) {
-            // write the Message to the Wire
-            TransportOutDescription transportOut = msgContext.getTransportOut();
-            if(transportOut == null) {
-                throw new AxisFault("Transport out has not been set");
-            }
-            TransportSender sender = transportOut.getSender();
-            // This boolean property only used in client side fireAndForget invocation
-            //It will set a property into message context and if some one has set the
-            //property then transport sender will invoke in a diffrent thread
-            Object isTransportNonBlocking = msgContext.getProperty(
-                    MessageContext.TRANSPORT_NON_BLOCKING);
-            if (isTransportNonBlocking != null && ((Boolean) isTransportNonBlocking).booleanValue()) {
-                msgContext.getConfigurationContext().getThreadPool().execute(
-                        new TransportNonBlockingInvocationWorker(msgContext, sender));
+                // write the Message to the Wire
+                TransportOutDescription transportOut = msgContext.getTransportOut();
+                if (transportOut == null) {
+                    throw new AxisFault("Transport out has not been set");
+                }
+                TransportSender sender = transportOut.getSender();
+                // This boolean property only used in client side fireAndForget invocation
+                //It will set a property into message context and if some one has set the
+                //property then transport sender will invoke in a diffrent thread
+                Object isTransportNonBlocking = msgContext.getProperty(
+                        MessageContext.TRANSPORT_NON_BLOCKING);
+                if (isTransportNonBlocking != null &&
+                        ((Boolean) isTransportNonBlocking).booleanValue()) {
+                    msgContext.getConfigurationContext().getThreadPool().execute(
+                            new TransportNonBlockingInvocationWorker(msgContext, sender));
+                } else {
+                    sender.invoke(msgContext);
+                }
+                //REVIEW: In the case of the TransportNonBlockingInvocationWorker, does this need to wait until that finishes?
+                flowComplete(msgContext, false);
+            } else if (pi.equals(InvocationResponse.SUSPEND)) {
+            } else if (pi.equals(InvocationResponse.ABORT)) {
+                flowComplete(msgContext, false);
             } else {
-                sender.invoke(msgContext);
+                String errorMsg =
+                        "Unrecognized InvocationResponse encountered in AxisEngine.send()";
+                log.error(msgContext.getLogIDString() + " " + errorMsg);
+                throw new AxisFault(errorMsg);
             }
-            //REVIEW: In the case of the TransportNonBlockingInvocationWorker, does this need to wait until that finishes?
-            flowComplete(msgContext, false);
-            } else if (pi.equals(InvocationResponse.SUSPEND)) {
-          }else if (pi.equals(InvocationResponse.ABORT)){
-            flowComplete(msgContext, false);
-          }else{
-            String errorMsg = "Unrecognized InvocationResponse encountered in AxisEngine.send()";
-            log.error(msgContext.getLogIDString()+" "+errorMsg);
-            throw new AxisFault(errorMsg);
-          }
         }
-        catch (AxisFault e){
-          flowComplete(msgContext, false);          
-          throw e;
+        catch (AxisFault e) {
+            flowComplete(msgContext, false);
+            throw e;
         }
     }
 
@@ -509,66 +516,70 @@
      * @throws AxisFault
      */
     public void sendFault(MessageContext msgContext) throws AxisFault {
-        if(LoggingControl.debugLoggingAllowed && log.isTraceEnabled()){
-            log.trace(msgContext.getLogIDString()+" sendFault:"+msgContext.getMessageID());
+        if (LoggingControl.debugLoggingAllowed && log.isTraceEnabled()) {
+            log.trace(msgContext.getLogIDString() + " sendFault:" + msgContext.getMessageID());
         }
         OperationContext opContext = msgContext.getOperationContext();
 
-        //FIXME: If this gets paused in the operation-specific phases, the resume is not going to function correctly as the phases will not have all been set 
-        
+        //FIXME: If this gets paused in the operation-specific phases, the resume is not going to function correctly as the phases will not have all been set
+
         // find and execute the Fault Out Flow Handlers
         if (opContext != null) {
             AxisOperation axisOperation = opContext.getAxisOperation();
             ArrayList faultExecutionChain = axisOperation.getPhasesOutFaultFlow();
 
             //adding both operation specific and global out fault flows.
-            
+
             ArrayList outFaultPhases = new ArrayList();
             outFaultPhases.addAll((ArrayList) faultExecutionChain.clone());
             msgContext.setExecutionChain((ArrayList) outFaultPhases.clone());
             msgContext.setFLOW(MessageContext.OUT_FAULT_FLOW);
             try {
-              InvocationResponse pi = invoke(msgContext, IS_OUTBOUND, NOT_RESUMING_EXECUTION);
-              
+                InvocationResponse pi = invoke(msgContext, IS_OUTBOUND, NOT_RESUMING_EXECUTION);
+
                 if (pi.equals(InvocationResponse.SUSPEND)) {
-                log.warn(msgContext.getLogIDString()+" The resumption of this flow may function incorrectly, as the OutFaultFlow will not be used");
-                return;
+                    log.warn(msgContext.getLogIDString() +
+                            " The resumption of this flow may function incorrectly, as the OutFaultFlow will not be used");
+                    return;
                 } else if (pi.equals(InvocationResponse.ABORT)) {
-                flowComplete(msgContext, false);
-                return;
+                    flowComplete(msgContext, false);
+                    return;
                 } else if (!pi.equals(InvocationResponse.CONTINUE)) {
-                String errorMsg = "Unrecognized InvocationResponse encountered in AxisEngine.sendFault()";
-                log.error(msgContext.getLogIDString()+" "+errorMsg);
-                throw new AxisFault(errorMsg);
-              }
+                    String errorMsg =
+                            "Unrecognized InvocationResponse encountered in AxisEngine.sendFault()";
+                    log.error(msgContext.getLogIDString() + " " + errorMsg);
+                    throw new AxisFault(errorMsg);
+                }
             }
             catch (AxisFault e) {
-              flowComplete(msgContext, false);
-              throw e;
+                flowComplete(msgContext, false);
+                throw e;
             }
         }
-        
-        msgContext.setExecutionChain((ArrayList) msgContext.getConfigurationContext().getAxisConfiguration().getOutFaultFlow().clone());
+
+        msgContext.setExecutionChain((ArrayList) msgContext.getConfigurationContext()
+                .getAxisConfiguration().getOutFaultFlow().clone());
         msgContext.setFLOW(MessageContext.OUT_FAULT_FLOW);
         InvocationResponse pi = invoke(msgContext, IS_OUTBOUND, NOT_RESUMING_EXECUTION);
 
         if (pi.equals(InvocationResponse.CONTINUE)) {
-          // Actually send the SOAP Fault
-          TransportOutDescription transportOut = msgContext.getTransportOut();
-          if(transportOut == null) {
-              throw new AxisFault("Transport out has not been set");
-          }
-          TransportSender sender = transportOut.getSender();
-
-          sender.invoke(msgContext);
-          flowComplete(msgContext, false);
-        }else if (pi.equals(InvocationResponse.SUSPEND)){
-        }else if (pi.equals(InvocationResponse.ABORT)){
-          flowComplete(msgContext, false);
-        }else{
-          String errorMsg = "Unrecognized InvocationResponse encountered in AxisEngine.sendFault()";
-          log.error(msgContext.getLogIDString()+" "+errorMsg);
-          throw new AxisFault(errorMsg);
+            // Actually send the SOAP Fault
+            TransportOutDescription transportOut = msgContext.getTransportOut();
+            if (transportOut == null) {
+                throw new AxisFault("Transport out has not been set");
+            }
+            TransportSender sender = transportOut.getSender();
+
+            sender.invoke(msgContext);
+            flowComplete(msgContext, false);
+        } else if (pi.equals(InvocationResponse.SUSPEND)) {
+        } else if (pi.equals(InvocationResponse.ABORT)) {
+            flowComplete(msgContext, false);
+        } else {
+            String errorMsg =
+                    "Unrecognized InvocationResponse encountered in AxisEngine.sendFault()";
+            log.error(msgContext.getLogIDString() + " " + errorMsg);
+            throw new AxisFault(errorMsg);
         }
     }
 
@@ -599,13 +610,15 @@
             try {
                 sender.invoke(msgctx);
             } catch (Exception e) {
-                log.info(msgctx.getLogIDString()+" "+e.getMessage());
-                if (msgctx.getProperty(MessageContext.DISABLE_ASYNC_CALLBACK_ON_TRANSPORT_ERROR) == null) {
+                log.info(msgctx.getLogIDString() + " " + e.getMessage());
+                if (msgctx.getProperty(MessageContext.DISABLE_ASYNC_CALLBACK_ON_TRANSPORT_ERROR) ==
+                        null) {
                     AxisOperation axisOperation = msgctx.getAxisOperation();
                     if (axisOperation != null) {
                         MessageReceiver msgReceiver = axisOperation.getMessageReceiver();
                         if ((msgReceiver != null) && (msgReceiver instanceof CallbackReceiver)) {
-                            Callback callback = ((CallbackReceiver)msgReceiver).lookupCallback(msgctx.getMessageID());
+                            Callback callback = ((CallbackReceiver) msgReceiver)
+                                    .lookupCallback(msgctx.getMessageID());
                             if (callback != null) {
                                 callback.onError(e);
                             }

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/engine/AxisEvent.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/engine/AxisEvent.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/engine/AxisEvent.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/engine/AxisEvent.java Sun Mar  4 10:16:54 2007
@@ -23,12 +23,12 @@
      * An Axis event is sent to registered listeners whenever anything significant
      * happens to <code>AxisConfiguration</code>.
      */
-    public static final int SERVICE_DEPLOY    = 1;
-    public static final int SERVICE_REMOVE    = 0;
-    public static final int SERVICE_STOP      = 2;
-    public static final int SERVICE_START     = 3;
-    public static final int MODULE_DEPLOY     = 4;
-    public static final int MODULE_REMOVE     = 5;
+    public static final int SERVICE_DEPLOY = 1;
+    public static final int SERVICE_REMOVE = 0;
+    public static final int SERVICE_STOP = 2;
+    public static final int SERVICE_START = 3;
+    public static final int MODULE_DEPLOY = 4;
+    public static final int MODULE_REMOVE = 5;
     private int EVENT_TYPE;
 
     public AxisEvent(int EVENT_TYPE) {

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/engine/DependencyManager.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/engine/DependencyManager.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/engine/DependencyManager.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/engine/DependencyManager.java Sun Mar  4 10:16:54 2007
@@ -50,7 +50,8 @@
             // We can not call classToLoad.getDeclaredMethed() , since there
             //  can be insatnce where mutiple services extends using one class
             // just for init and other reflection methods
-            Method method = classToLoad.getMethod(SERVICE_INIT_METHOD, new Class[]{ServiceContext.class});
+            Method method =
+                    classToLoad.getMethod(SERVICE_INIT_METHOD, new Class[]{ServiceContext.class});
             if (method != null) {
                 method.invoke(obj, new Object[]{serviceContext});
             }
@@ -79,7 +80,7 @@
         while (serviceItr.hasNext()) {
             AxisService axisService = (AxisService) serviceItr.next();
             ServiceContext serviceContext = ContextFactory.createServiceContext(
-                    serviceGroupContext,axisService);
+                    serviceGroupContext, axisService);
             AxisService service = serviceContext.getAxisService();
             ClassLoader classLoader = service.getClassLoader();
             Parameter implInfoParam = service.getParameter(Constants.SERVICE_CLASS);

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/engine/DispatchPhase.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/engine/DispatchPhase.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/engine/DispatchPhase.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/engine/DispatchPhase.java Sun Mar  4 10:16:54 2007
@@ -43,11 +43,11 @@
 
         if (msgContext.getAxisService() == null) {
             throw new AxisFault(Messages.getMessage("servicenotfoundforepr",
-                    ((toEPR != null) ? toEPR.getAddress() : "")));
+                                                    ((toEPR != null) ? toEPR.getAddress() : "")));
         } else if (msgContext.getAxisOperation() == null) {
             throw new AxisFault(Messages.getMessage("operationnotfoundforepr",
-                    ((toEPR != null) ? toEPR.getAddress()
-                            : ""), msgContext.getWSAAction()));
+                                                    ((toEPR != null) ? toEPR.getAddress()
+                                                            : ""), msgContext.getWSAAction()));
         }
 
         validateTransport(msgContext);
@@ -66,7 +66,7 @@
         if ((msgContext.getAxisService() == null) && (msgContext.getServiceContext() != null)) {
             msgContext.setAxisService(msgContext.getServiceContext().getAxisService());
         }
-        
+
         //TODO: The same thing should probably happen for a IN-OUT if addressing is enabled and the replyTo/faultTo are not anonymous 
         if (msgContext.getAxisOperation().getMessageExchangePattern()
                 .equals(WSDL20_2004_Constants.MEP_URI_IN_ONLY)) {
@@ -77,7 +77,8 @@
                         .acknowledgeMessage(msgContext);
             }
         } else if (msgContext.getAxisOperation().getMessageExchangePattern()
-                .equals(WSDL20_2004_Constants.MEP_URI_IN_OUT)) {   // OR, if 2 way operation but the response is intended to not use the response channel of a 2-way transport
+                .equals(WSDL20_2004_Constants.MEP_URI_IN_OUT))
+        {   // OR, if 2 way operation but the response is intended to not use the response channel of a 2-way transport
             // then we don't need to keep the transport waiting.
             Object requestResponseTransport =
                     msgContext.getProperty(RequestResponseTransport.TRANSPORT_CONTROL);
@@ -117,6 +118,6 @@
         }
         EndpointReference toEPR = msgctx.getTo();
         throw new AxisFault(Messages.getMessage("servicenotfoundforepr",
-                ((toEPR != null) ? toEPR.getAddress() : "")));
+                                                ((toEPR != null) ? toEPR.getAddress() : "")));
     }
 }

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/engine/HTTPLocationBasedDispatcher.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/engine/HTTPLocationBasedDispatcher.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/engine/HTTPLocationBasedDispatcher.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/engine/HTTPLocationBasedDispatcher.java Sun Mar  4 10:16:54 2007
@@ -49,7 +49,8 @@
         AxisService axisService = messageContext.getAxisService();
         if (axisService != null) {
             String uri = messageContext.getTo().getAddress();
-            String httpLocation = parseRequestURL(uri, messageContext.getConfigurationContext().getServiceContextPath());
+            String httpLocation = parseRequestURL(uri, messageContext
+                    .getConfigurationContext().getServiceContextPath());
 
             if (httpLocation != null) {
                 AxisEndpoint axisEndpoint = (AxisEndpoint) messageContext
@@ -97,7 +98,7 @@
 
         index = service.indexOf("/");
         if (-1 != index) {
-                service = service.substring(index);
+            service = service.substring(index);
         } else {
             int queryIndex = path.indexOf("?");
             if (queryIndex != -1) {

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/engine/Handler.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/engine/Handler.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/engine/Handler.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/engine/Handler.java Sun Mar  4 10:16:54 2007
@@ -28,7 +28,7 @@
 public interface Handler {
 
     /**
-     * Since this might change the whole behavior of Axis2 handlers, and since this is still under discussion 
+     * Since this might change the whole behavior of Axis2 handlers, and since this is still under discussion
      * (http://marc.theaimsgroup.com/?l=axis-dev&m=114504084929285&w=2) implementation of this method is deferred.
      * Note : This method will not be automatically called, from Axis2 engine, until this is fully implemented.
      */
@@ -57,7 +57,7 @@
      *
      * @param msgContext the <code>MessageContext</code> to process with this
      *                   <code>Handler</code>.
-     * @return An InvocationResponse that indicates what 
+     * @return An InvocationResponse that indicates what
      *         the next step in the message processing should be.
      * @throws AxisFault if the handler encounters an error
      */
@@ -69,12 +69,12 @@
      * the message processing has completed.  During execution of the
      * flowComplete's, handlers are invoked in the opposite order that they
      * were invoked originally.
-     * 
+     *
      * @param msgContext the <code>MessageContext</code> to process with this
      *                   <code>Handler</code>.
      */
     public void flowComplete(MessageContext msgContext);
-    
+
     /**
      * Gets the HandlerDescription of a handler. This is used as an input to get phaseRule of a handler.
      *
@@ -96,7 +96,7 @@
      * @return Returns Parameter.
      */
     public Parameter getParameter(String name);
-    
+
     /**
      * This type encapsulates an enumeration of possible message processing
      * instruction values that may be returned by a handler/phase within the
@@ -104,36 +104,39 @@
      * the processing.
      */
     public class InvocationResponse {
-      public static InvocationResponse CONTINUE = new InvocationResponse(0, "InvocationResponse.CONTINUE");
-      public static InvocationResponse SUSPEND = new InvocationResponse(1, "InvocationResponse.SUSPEND");
-      public static InvocationResponse ABORT = new InvocationResponse(2, "InvocationResponse.ABORT");
-
-      private int instructionID;
-      private String description;
-        
+        public static InvocationResponse CONTINUE =
+                new InvocationResponse(0, "InvocationResponse.CONTINUE");
+        public static InvocationResponse SUSPEND =
+                new InvocationResponse(1, "InvocationResponse.SUSPEND");
+        public static InvocationResponse ABORT =
+                new InvocationResponse(2, "InvocationResponse.ABORT");
+
+        private int instructionID;
+        private String description;
+
         private InvocationResponse(int instructionID, String description) {
-        this.instructionID = instructionID;
-        this.description = description;
-      }
-        
+            this.instructionID = instructionID;
+            this.description = description;
+        }
+
         public boolean equals(InvocationResponse instruction) {
-        return this.instructionID == instruction.instructionID;
-      }
-        
+            return this.instructionID == instruction.instructionID;
+        }
+
         public int hashCode() {
-        return instructionID;
-      }
-      
-      public boolean equals(Object obj) {
-        if( !(obj instanceof InvocationResponse) ) {
-            return false;
+            return instructionID;
+        }
+
+        public boolean equals(Object obj) {
+            if (!(obj instanceof InvocationResponse)) {
+                return false;
+            }
+            final InvocationResponse instance = (InvocationResponse) obj;
+            return (instructionID == instance.instructionID);
+        }
+
+        public String toString() {
+            return description;
         }
-        final InvocationResponse instance = (InvocationResponse)obj;
-        return (instructionID==instance.instructionID);
-      }
-
-      public String toString() {
-          return description;
-      }
     }
 }

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/engine/InstanceDispatcher.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/engine/InstanceDispatcher.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/engine/InstanceDispatcher.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/engine/InstanceDispatcher.java Sun Mar  4 10:16:54 2007
@@ -45,7 +45,8 @@
  */
 public class InstanceDispatcher extends AbstractHandler {
     private static final QName SERVICE_GROUP_QNAME = new QName(Constants.AXIS2_NAMESPACE_URI,
-            Constants.SERVICE_GROUP_ID, Constants.AXIS2_NAMESPACE_PREFIX);
+                                                               Constants.SERVICE_GROUP_ID,
+                                                               Constants.AXIS2_NAMESPACE_PREFIX);
 
     /**
      * Post Condition : All the Contexts must be populated.
@@ -65,10 +66,10 @@
 
             return InvocationResponse.CONTINUE;
         }
-        if(Constants.SCOPE_TRANSPORT_SESSION.equals(scope)){
+        if (Constants.SCOPE_TRANSPORT_SESSION.equals(scope)) {
             fillContextsFromSessionContext(msgContext);
-        } else if(Constants.SCOPE_SOAP_SESSION.equals(scope)){
-             extractServiceGroupContextId(msgContext);
+        } else if (Constants.SCOPE_SOAP_SESSION.equals(scope)) {
+            extractServiceGroupContextId(msgContext);
         }
 
         AxisOperation axisOperation = msgContext.getAxisOperation();
@@ -92,7 +93,7 @@
             msgContext.setServiceGroupContext(serviceGroupContext);
             msgContext.setServiceGroupContextId(serviceGroupContext.getId());
         } else {    // 2. if null, create new opCtxt
-            operationContext =ContextFactory.createOperationContext(axisOperation,serviceContext);
+            operationContext = ContextFactory.createOperationContext(axisOperation, serviceContext);
 
             axisOperation.registerMessageContext(msgContext, operationContext);
             if (serviceContext != null) {
@@ -121,7 +122,7 @@
         if (sessionContext == null) {
             TransportListener listener = msgContext.getTransportIn().getReceiver();
             sessionContext = listener.getSessionContext(msgContext);
-            if(sessionContext==null){
+            if (sessionContext == null) {
                 createAndFillContexts(service, msgContext, sessionContext);
                 return;
             }
@@ -134,7 +135,7 @@
             msgContext.setServiceGroupContext(serviceGroupContext);
             // setting Service conetxt
             msgContext.setServiceContext(
-                    ContextFactory.createServiceContext(serviceGroupContext,service));
+                    ContextFactory.createServiceContext(serviceGroupContext, service));
         } else {
             createAndFillContexts(service, msgContext, sessionContext);
         }
@@ -147,17 +148,18 @@
     }
 
     private void createAndFillContexts(AxisService service,
-                                                     MessageContext msgContext,
-                                                     SessionContext sessionContext) throws AxisFault {
+                                       MessageContext msgContext,
+                                       SessionContext sessionContext) throws AxisFault {
         ServiceGroupContext serviceGroupContext;
         AxisServiceGroup axisServiceGroup = (AxisServiceGroup) service.getParent();
         serviceGroupContext = ContextFactory.createServiceGroupContext(
                 msgContext.getConfigurationContext(), axisServiceGroup);
 
         msgContext.setServiceGroupContext(serviceGroupContext);
-        ServiceContext serviceContext =ContextFactory.createServiceContext(serviceGroupContext,service);
+        ServiceContext serviceContext =
+                ContextFactory.createServiceContext(serviceGroupContext, service);
         msgContext.setServiceContext(serviceContext);
-        if(sessionContext!=null){
+        if (sessionContext != null) {
             sessionContext.addServiceContext(serviceContext);
             sessionContext.addServiceGroupContext(serviceGroupContext);
         }

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/engine/ListenerManager.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/engine/ListenerManager.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/engine/ListenerManager.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/engine/ListenerManager.java Sun Mar  4 10:16:54 2007
@@ -74,7 +74,8 @@
                 Iterator itr_st = startedTransports.values().iterator();
                 while (itr_st.hasNext()) {
                     TransportListener transportListener = (TransportListener) itr_st.next();
-                    EndpointReference[] epRsForService = transportListener.getEPRsForService(serviceName, null);
+                    EndpointReference[] epRsForService =
+                            transportListener.getEPRsForService(serviceName, null);
                     if (epRsForService != null) {
                         return epRsForService[0];
                     }
@@ -121,7 +122,8 @@
             try {
                 TransportInDescription transportIn = (TransportInDescription) transportNames.next();
                 TransportListener listener = transportIn.getReceiver();
-                if (listener != null && startedTransports.get(transportIn.getName().getLocalPart()) == null) {
+                if (listener != null &&
+                        startedTransports.get(transportIn.getName().getLocalPart()) == null) {
                     listener.init(configctx, transportIn);
                     listener.start();
                     if (startedTransports.get(transportIn.getName().getLocalPart()) == null) {
@@ -196,7 +198,8 @@
      * @param started : whether transport Listener running or not
      * @throws AxisFault : will throw AxisFault if something goes wrong
      */
-    public synchronized void addListener(TransportInDescription trsIn, boolean started) throws AxisFault {
+    public synchronized void addListener(TransportInDescription trsIn, boolean started)
+            throws AxisFault {
         configctx.getAxisConfiguration().addTransportIn(trsIn);
         TransportListener transportListener = trsIn.getReceiver();
         if (transportListener != null) {

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/engine/Phase.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/engine/Phase.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/engine/Phase.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/engine/Phase.java Sun Mar  4 10:16:54 2007
@@ -357,9 +357,10 @@
      */
     public final InvocationResponse invoke(MessageContext msgctx) throws AxisFault {
         if (LoggingControl.debugLoggingAllowed && log.isDebugEnabled()) {
-            log.debug(msgctx.getLogIDString()+" Checking pre-condition for Phase \"" + phaseName + "\"");
+            log.debug(msgctx.getLogIDString() + " Checking pre-condition for Phase \"" + phaseName +
+                    "\"");
         }
-        
+
         InvocationResponse pi = InvocationResponse.CONTINUE;
 
         int currentIndex = msgctx.getCurrentPhaseIndex();
@@ -369,19 +370,20 @@
         }
 
         if (LoggingControl.debugLoggingAllowed && log.isDebugEnabled()) {
-            log.debug(msgctx.getLogIDString()+" Invoking phase \"" + phaseName + "\"");
+            log.debug(msgctx.getLogIDString() + " Invoking phase \"" + phaseName + "\"");
         }
 
         while (currentIndex < handlers.size()) {
             Handler handler = (Handler) handlers.get(currentIndex);
 
             if (LoggingControl.debugLoggingAllowed && log.isDebugEnabled()) {
-                log.debug(msgctx.getLogIDString()+" Invoking Handler '" + handler.getName() + "' in Phase '" + phaseName + "'");
+                log.debug(msgctx.getLogIDString() + " Invoking Handler '" + handler.getName() +
+                        "' in Phase '" + phaseName + "'");
             }
             pi = handler.invoke(msgctx);
 
             if (!pi.equals(InvocationResponse.CONTINUE)) {
-              return pi;
+                return pi;
             }
 
             currentIndex++;
@@ -389,7 +391,8 @@
         }
 
         if (LoggingControl.debugLoggingAllowed && log.isDebugEnabled()) {
-            log.debug(msgctx.getLogIDString()+" Checking post-conditions for phase \"" + phaseName + "\"");
+            log.debug(msgctx.getLogIDString() + " Checking post-conditions for phase \"" +
+                    phaseName + "\"");
         }
 
         msgctx.setCurrentPhaseIndex(0);
@@ -399,31 +402,33 @@
 
     public void flowComplete(MessageContext msgContext) {
         if (LoggingControl.debugLoggingAllowed && log.isDebugEnabled()) {
-        log.debug(msgContext.getLogIDString()+" Invoking flowComplete() in Phase \"" + phaseName + "\"");
-      }
-      
-      /*This will be non-zero if we failed during execution of one of the
-       *handlers in this phase*/
-      int currentHandlerIndex = msgContext.getCurrentPhaseIndex();
+            log.debug(msgContext.getLogIDString() + " Invoking flowComplete() in Phase \"" +
+                    phaseName + "\"");
+        }
+
+        /*This will be non-zero if we failed during execution of one of the
+     *handlers in this phase*/
+        int currentHandlerIndex = msgContext.getCurrentPhaseIndex();
         if (currentHandlerIndex == 0) {
-        currentHandlerIndex = handlers.size();
+            currentHandlerIndex = handlers.size();
         } else {
-        /*We need to set it to 0 so that any previous phases will execute all
+            /*We need to set it to 0 so that any previous phases will execute all
          * of their handlers.*/
-        msgContext.setCurrentPhaseIndex(0);
-      }
-      
+            msgContext.setCurrentPhaseIndex(0);
+        }
+
         for (; currentHandlerIndex > 0; currentHandlerIndex--) {
-        Handler handler = (Handler) handlers.get(currentHandlerIndex-1);
-        
+            Handler handler = (Handler) handlers.get(currentHandlerIndex - 1);
+
             if (LoggingControl.debugLoggingAllowed && log.isDebugEnabled()) {
-          log.debug(msgContext.getLogIDString()+" Invoking flowComplete() for Handler '" + handler.getName() + "' in Phase '" + phaseName + "'");
+                log.debug(msgContext.getLogIDString() + " Invoking flowComplete() for Handler '" +
+                        handler.getName() + "' in Phase '" + phaseName + "'");
+            }
+
+            handler.flowComplete(msgContext);
         }
-        
-        handler.flowComplete(msgContext);
-      }
     }
-    
+
     public String toString() {
         return this.getPhaseName();
     }

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/engine/RequestURIBasedDispatcher.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/engine/RequestURIBasedDispatcher.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/engine/RequestURIBasedDispatcher.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/engine/RequestURIBasedDispatcher.java Sun Mar  4 10:16:54 2007
@@ -48,7 +48,7 @@
             throws AxisFault {
         // This Dispatcher does not need to resolve the operation, as that is handled
         // by the RequestURIOperationDispatcher.
-                return null;
+        return null;
     }
 
     /*

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/engine/RequestURIOperationDispatcher.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/engine/RequestURIOperationDispatcher.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/engine/RequestURIOperationDispatcher.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/engine/RequestURIOperationDispatcher.java Sun Mar  4 10:16:54 2007
@@ -48,19 +48,24 @@
         if (toEPR != null) {
             String filePart = toEPR.getAddress();
             String[] values = Utils.parseRequestURLForServiceAndOperation(filePart,
-                    messageContext.getConfigurationContext().getServiceContextPath());
+                                                                          messageContext
+                                                                                  .getConfigurationContext().getServiceContextPath());
 
             if ((values.length >= 2) && (values[1] != null)) {
                 QName operationName = new QName(values[1]);
-                log.debug(messageContext.getLogIDString()+" Checking for Operation using QName(target endpoint URI fragment) : " + operationName);
+                log.debug(messageContext.getLogIDString() +
+                        " Checking for Operation using QName(target endpoint URI fragment) : " +
+                        operationName);
                 AxisOperation axisOperation = service.getOperation(operationName);
                 return axisOperation;
             } else {
-                log.debug(messageContext.getLogIDString()+" Attempted to check for Operation using target endpoint URI, but the operation fragment was missing");
+                log.debug(messageContext.getLogIDString() +
+                        " Attempted to check for Operation using target endpoint URI, but the operation fragment was missing");
                 return null;
             }
         } else {
-            log.debug(messageContext.getLogIDString()+" Attempted to check for Operation using null target endpoint URI");
+            log.debug(messageContext.getLogIDString() +
+                    " Attempted to check for Operation using null target endpoint URI");
             return null;
         }
     }

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/engine/SOAPActionBasedDispatcher.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/engine/SOAPActionBasedDispatcher.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/engine/SOAPActionBasedDispatcher.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/engine/SOAPActionBasedDispatcher.java Sun Mar  4 10:16:54 2007
@@ -43,7 +43,7 @@
             throws AxisFault {
         String action = messageContext.getSoapAction();
 
-        if(LoggingControl.debugLoggingAllowed && log.isDebugEnabled()){
+        if (LoggingControl.debugLoggingAllowed && log.isDebugEnabled()) {
             log.debug(messageContext.getLogIDString() +
                     " Checking for Operation using SOAPAction : " + action);
         }
@@ -75,8 +75,9 @@
      * @see org.apache.axis2.engine.AbstractDispatcher#findService(org.apache.axis2.context.MessageContext)
      */
     public AxisService findService(MessageContext messageContext) throws AxisFault {
-        if(LoggingControl.debugLoggingAllowed && log.isDebugEnabled()){
-        log.debug(messageContext.getLogIDString()+" Checking for Service using SOAPAction is a TODO item");
+        if (LoggingControl.debugLoggingAllowed && log.isDebugEnabled()) {
+            log.debug(messageContext.getLogIDString() +
+                    " Checking for Service using SOAPAction is a TODO item");
         }
         return null;
     }

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/engine/SOAPMessageBodyBasedDispatcher.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/engine/SOAPMessageBodyBasedDispatcher.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/engine/SOAPMessageBodyBasedDispatcher.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/engine/SOAPMessageBodyBasedDispatcher.java Sun Mar  4 10:16:54 2007
@@ -46,17 +46,17 @@
 
     public AxisOperation findOperation(AxisService service, MessageContext messageContext)
             throws AxisFault {
-        QName operationName ;
-        
+        QName operationName;
+
         OMElement bodyFirstChild = messageContext.getEnvelope().getBody().getFirstElement();
 
         if (bodyFirstChild == null) {
             return null;
         } else {
-            if(LoggingControl.debugLoggingAllowed && log.isDebugEnabled()){
-            log.debug(messageContext.getLogIDString()+
-                    " Checking for Operation using SOAP message body's first child's local name : "
-                            + bodyFirstChild.getLocalName());
+            if (LoggingControl.debugLoggingAllowed && log.isDebugEnabled()) {
+                log.debug(messageContext.getLogIDString() +
+                        " Checking for Operation using SOAP message body's first child's local name : "
+                        + bodyFirstChild.getLocalName());
             }
             operationName = new QName(bodyFirstChild.getLocalName());
         }
@@ -66,7 +66,7 @@
         if (axisOperation == null) {
             axisOperation = service.getOperationByMessageElementQName(bodyFirstChild.getQName());
         }
-        
+
         return axisOperation;
     }
 
@@ -75,8 +75,8 @@
      * @see org.apache.axis2.engine.AbstractDispatcher#findService(org.apache.axis2.context.MessageContext)
      */
     public AxisService findService(MessageContext messageContext) throws AxisFault {
-        String serviceName ;
-        
+        String serviceName;
+
         OMElement bodyFirstChild = messageContext.getEnvelope().getBody().getFirstElement();
 
         if (bodyFirstChild != null) {
@@ -85,14 +85,15 @@
             if (ns != null) {
                 String filePart = ns.getNamespaceURI();
 
-                if(LoggingControl.debugLoggingAllowed && log.isDebugEnabled()){
-                log.debug(messageContext.getLogIDString()+
-                        " Checking for Service using SOAP message body's first child's namespace : "
-                                + filePart);
+                if (LoggingControl.debugLoggingAllowed && log.isDebugEnabled()) {
+                    log.debug(messageContext.getLogIDString() +
+                            " Checking for Service using SOAP message body's first child's namespace : "
+                            + filePart);
                 }
-                ConfigurationContext configurationContext = messageContext.getConfigurationContext();
+                ConfigurationContext configurationContext =
+                        messageContext.getConfigurationContext();
                 String[] values = Utils.parseRequestURLForServiceAndOperation(filePart,
-                        configurationContext.getServiceContextPath());
+                                                                              configurationContext.getServiceContextPath());
 
                 if (values[0] != null) {
                     serviceName = values[0];

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/handlers/AbstractHandler.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/handlers/AbstractHandler.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/handlers/AbstractHandler.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/handlers/AbstractHandler.java Sun Mar  4 10:16:54 2007
@@ -101,7 +101,7 @@
     public Parameter getParameter(String name) {
         return handlerDesc.getParameter(name);
     }
-    
+
     public void flowComplete(MessageContext msgContext) {
     }
 }

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/i18n/MessageBundle.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/i18n/MessageBundle.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/i18n/MessageBundle.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/i18n/MessageBundle.java Sun Mar  4 10:16:54 2007
@@ -42,11 +42,11 @@
     public final ProjectResourceBundle getResourceBundle() {
         if (!loaded) {
             _resourceBundle = ProjectResourceBundle.getBundle(projectName,
-                    packageName,
-                    resourceName,
-                    locale,
-                    classLoader,
-                    parent);
+                                                              packageName,
+                                                              resourceName,
+                                                              locale,
+                                                              classLoader,
+                                                              parent);
             loaded = true;
         }
         return _resourceBundle;
@@ -127,7 +127,8 @@
      * @param arg2 The argument to place in variable {2}
      * @return The message
      */
-    public String getMessage(String key, String arg0, String arg1, String arg2) throws MissingResourceException {
+    public String getMessage(String key, String arg0, String arg1, String arg2)
+            throws MissingResourceException {
         return getMessage(key, new String[]{arg0, arg1, arg2});
     }
 
@@ -146,7 +147,8 @@
      * @param arg3 The argument to place in variable {3}
      * @return The message
      */
-    public String getMessage(String key, String arg0, String arg1, String arg2, String arg3) throws MissingResourceException {
+    public String getMessage(String key, String arg0, String arg1, String arg2, String arg3)
+            throws MissingResourceException {
         return getMessage(key, new String[]{arg0, arg1, arg2, arg3});
     }
 
@@ -166,7 +168,8 @@
      * @param arg4 The argument to place in variable {4}
      * @return The message
      */
-    public String getMessage(String key, String arg0, String arg1, String arg2, String arg3, String arg4) throws MissingResourceException {
+    public String getMessage(String key, String arg0, String arg1, String arg2, String arg3,
+                             String arg4) throws MissingResourceException {
         return getMessage(key, new String[]{arg0, arg1, arg2, arg3, arg4});
     }
 
@@ -192,7 +195,7 @@
             throw new MissingResourceException("Cannot find resource key \"" + key +
                     "\" in base name " +
                     getResourceBundle().getResourceName(),
-                    getResourceBundle().getResourceName(), key);
+                                               getResourceBundle().getResourceName(), key);
         }
 
         return MessageFormat.format(msg, array);

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/i18n/Messages.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/i18n/Messages.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/i18n/Messages.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/i18n/Messages.java Sun Mar  4 10:16:54 2007
@@ -45,7 +45,7 @@
     static {
         MessageBundle defaultMessageBundle =
                 new MessageBundle(projectName, packageName, resourceName,
-                        locale, classLoader, parent);
+                                  locale, classLoader, parent);
         addMessageBundle(DEFAULT_MESSAGE_BUNDLE_KEY, defaultMessageBundle);
     }
 
@@ -140,7 +140,8 @@
      * @param arg4 The argument to place in variable {4}
      * @return The formatted message
      */
-    public static String getMessage(String key, String arg0, String arg1, String arg2, String arg3, String arg4)
+    public static String getMessage(String key, String arg0, String arg1, String arg2, String arg3,
+                                    String arg4)
             throws MissingResourceException {
         MessageBundle messageBundle = getMessageBundle(DEFAULT_MESSAGE_BUNDLE_KEY);
         return messageBundle.getMessage(key, arg0, arg1, arg2, arg3, arg4);
@@ -216,7 +217,8 @@
      * @param arg1             The argument to place in variable {1}
      * @return The formatted message
      */
-    public static String getMessageFromBundle(String messageBundleKey, String key, String arg0, String arg1)
+    public static String getMessageFromBundle(String messageBundleKey, String key, String arg0,
+                                              String arg1)
             throws MissingResourceException, Exception {
         MessageBundle messageBundle = getMessageBundle(messageBundleKey);
         if (messageBundle == null) {
@@ -236,7 +238,8 @@
      * @param arg2             The argument to place in variable {2}
      * @return The formatted message
      */
-    public static String getMessageFromBundle(String messageBundleKey, String key, String arg0, String arg1, String arg2)
+    public static String getMessageFromBundle(String messageBundleKey, String key, String arg0,
+                                              String arg1, String arg2)
             throws MissingResourceException, Exception {
         MessageBundle messageBundle = getMessageBundle(messageBundleKey);
         if (messageBundle == null) {
@@ -257,7 +260,8 @@
      * @param arg3             The argument to place in variable {3}
      * @return The formatted message
      */
-    public static String getMessageFromBundle(String messageBundleKey, String key, String arg0, String arg1, String arg2, String arg3)
+    public static String getMessageFromBundle(String messageBundleKey, String key, String arg0,
+                                              String arg1, String arg2, String arg3)
             throws MissingResourceException, Exception {
         MessageBundle messageBundle = getMessageBundle(messageBundleKey);
         if (messageBundle == null) {
@@ -279,7 +283,8 @@
      * @param arg4             The argument to place in variable {4}
      * @return The formatted message
      */
-    public static String getMessageFromBundle(String messageBundleKey, String key, String arg0, String arg1, String arg2, String arg3, String arg4)
+    public static String getMessageFromBundle(String messageBundleKey, String key, String arg0,
+                                              String arg1, String arg2, String arg3, String arg4)
             throws MissingResourceException, Exception {
         MessageBundle messageBundle = getMessageBundle(messageBundleKey);
         if (messageBundle == null) {

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/i18n/MessagesConstants.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/i18n/MessagesConstants.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/i18n/MessagesConstants.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/i18n/MessagesConstants.java Sun Mar  4 10:16:54 2007
@@ -28,9 +28,9 @@
 
     public static final ResourceBundle rootBundle =
             ProjectResourceBundle.getBundle(projectName,
-                    rootPackageName,
-                    resourceName,
-                    locale,
-                    MessagesConstants.class.getClassLoader(),
-                    null);
+                                            rootPackageName,
+                                            resourceName,
+                                            locale,
+                                            MessagesConstants.class.getClassLoader(),
+                                            null);
 }

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/i18n/ProjectResourceBundle.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/i18n/ProjectResourceBundle.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/i18n/ProjectResourceBundle.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/i18n/ProjectResourceBundle.java Sun Mar  4 10:16:54 2007
@@ -147,10 +147,10 @@
                                                   Locale locale)
             throws MissingResourceException {
         return getBundle(projectName,
-                caller,
-                resourceName,
-                locale,
-                null);
+                         caller,
+                         resourceName,
+                         locale,
+                         null);
     }
 
     /**
@@ -199,11 +199,11 @@
                                                   ResourceBundle extendsBundle)
             throws MissingResourceException {
         return getBundle(projectName,
-                getPackage(caller.getClass().getName()),
-                resourceName,
-                locale,
-                caller.getClass().getClassLoader(),
-                extendsBundle);
+                         getPackage(caller.getClass().getName()),
+                         resourceName,
+                         locale,
+                         caller.getClass().getClassLoader(),
+                         extendsBundle);
     }
 
     /**
@@ -211,8 +211,8 @@
      *
      * @param projectName   The name of the project to which the class belongs.
      *                      It must be a proper prefix of the caller's package.
-     * @param packageName  The package name to further construct
-     *                     the basename.
+     * @param packageName   The package name to further construct
+     *                      the basename.
      * @param resourceName  The name of the resource without the
      *                      ".properties" extension
      * @param locale        The locale
@@ -256,7 +256,7 @@
         if (bundle == null) {
             throw new MissingResourceException("Cannot find resource '" +
                     packageName + '.' + resourceName + "'",
-                    resourceName, "");
+                                               resourceName, "");
         }
 
         return bundle;
@@ -330,7 +330,6 @@
 //    public static void clearCache() {
 //        bundleCache.clear();
 //    }
-
     public String toString() {
         return resourceName;
     }
@@ -396,14 +395,15 @@
 
         String getCacheKey(String packageName) {
             String loaderName = (_loader == null) ? "" : (":" + _loader.hashCode());
-            return packageName + "." + _resourceName + ":" + _locale + ":" + defaultLocale + loaderName;
+            return packageName + "." + _resourceName + ":" + _locale + ":" + defaultLocale +
+                    loaderName;
         }
 
         ResourceBundle loadBundle(String packageName) {
             try {
                 return ResourceBundle.getBundle(packageName + '.' + _resourceName,
-                        _locale,
-                        _loader);
+                                                _locale,
+                                                _loader);
             } catch (MissingResourceException e) {
                 // Deliberately surpressing print stack.. just the string for info.
                 log.debug("loadBundle: Ignoring MissingResourceException: " + e.getMessage());
@@ -427,25 +427,25 @@
             if (_projectName == null || _projectName.length() == 0) {
                 log.debug("Project name not specified");
                 throw new MissingResourceException("Project name not specified",
-                        "", "");
+                                                   "", "");
             }
 
             if (packageName == null || packageName.length() == 0) {
                 log.debug("Package name not specified");
                 throw new MissingResourceException("Package not specified",
-                        packageName, "");
+                                                   packageName, "");
             }
             packageName = packageName.intern();
-    
+
             /* Ensure that project is a proper prefix of class.
-             * Terminate project name with '.' to ensure proper match.
-             */
+            * Terminate project name with '.' to ensure proper match.
+            */
             if (!packageName.equals(_projectName) && !packageName.startsWith(_projectName + '.')) {
                 log.debug("Project not a prefix of Package");
                 throw new MissingResourceException("Project '" + _projectName
                         + "' must be a prefix of Package '"
                         + packageName + "'",
-                        packageName + '.' + _resourceName, "");
+                                                   packageName + '.' + _resourceName, "");
             }
 
             return packageName;

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/i18n/RB.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/i18n/RB.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/i18n/RB.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/i18n/RB.java Sun Mar  4 10:16:54 2007
@@ -104,7 +104,7 @@
      * @param caller The calling object. This is used to get the package name
      *               to further construct the basename as well as to get the proper ClassLoader
      * @param name   The name of the property file without the ".properties" extension
-     * @param locale  The locale
+     * @param locale The locale
      */
     public RB(Object caller, String name, Locale locale) throws MissingResourceException {
         ClassLoader cl = null;
@@ -214,7 +214,8 @@
      * @param arg2 The argument to place in variable {1}
      * @return The message
      */
-    public String getString(String key, Object arg0, Object arg1, Object arg2) throws MissingResourceException {
+    public String getString(String key, Object arg0, Object arg1, Object arg2)
+            throws MissingResourceException {
         Object[] o = new Object[3];
         o[0] = arg0;
         o[1] = arg1;
@@ -243,7 +244,7 @@
         if (msg == null) {
             throw new MissingResourceException("Cannot find resource key \"" + key +
                     "\" in base name " + basePropertyFileName,
-                    basePropertyFileName, key);
+                                               basePropertyFileName, key);
         }
 
         msg = MessageFormat.format(msg, array);
@@ -307,8 +308,9 @@
             if (country != null) {
 
                 if (variant != null) {
-                    props = merge(props, loadProperties(basename + "_" + language + "_" + country + "_" + variant +
-                            PROPERTY_EXT, loader));
+                    props = merge(props, loadProperties(
+                            basename + "_" + language + "_" + country + "_" + variant +
+                                    PROPERTY_EXT, loader));
                 }
                 props = merge(props, loadProperties(basename + "_" + language + "_" + country +
                         PROPERTY_EXT, loader));
@@ -462,7 +464,8 @@
      * @param arg3   The argument to place in variable {3}
      * @return The formatted message
      */
-    public static String getString(Object caller, String key, Object arg0, Object arg1, Object arg2, Object arg3)
+    public static String getString(Object caller, String key, Object arg0, Object arg1, Object arg2,
+                                   Object arg3)
             throws MissingResourceException {
         Object[] o = new Object[4];
         o[0] = arg0;
@@ -485,7 +488,8 @@
      * @param arg4   The argument to place in variable {4}
      * @return Returns the formatted message.
      */
-    public static String getString(Object caller, String key, Object arg0, Object arg1, Object arg2, Object arg3, Object arg4)
+    public static String getString(Object caller, String key, Object arg0, Object arg1, Object arg2,
+                                   Object arg3, Object arg4)
             throws MissingResourceException {
         Object[] o = new Object[5];
         o[0] = arg0;
@@ -502,7 +506,7 @@
      *
      * @param caller The calling object, used to get the package name and class loader
      * @param key    The resource key
-     * @param args  An array of objects to place in corresponding variables
+     * @param args   An array of objects to place in corresponding variables
      * @return Returns the formatted message.
      */
     public static String getString(Object caller, String key, Object[] args)
@@ -550,7 +554,8 @@
      * @param arg1   The argument to place in variable {1}
      * @return The formatted message
      */
-    public static String getString(Object caller, Locale locale, String key, Object arg0, Object arg1)
+    public static String getString(Object caller, Locale locale, String key, Object arg0,
+                                   Object arg1)
             throws MissingResourceException {
         Object[] o = new Object[2];
         o[0] = arg0;
@@ -569,7 +574,8 @@
      * @param arg2   The argument to place in variable {2}
      * @return The formatted message
      */
-    public static String getString(Object caller, Locale locale, String key, Object arg0, Object arg1, Object arg2)
+    public static String getString(Object caller, Locale locale, String key, Object arg0,
+                                   Object arg1, Object arg2)
             throws MissingResourceException {
         Object[] o = new Object[3];
         o[0] = arg0;
@@ -590,7 +596,8 @@
      * @param arg3   The argument to place in variable {3}
      * @return The formatted message
      */
-    public static String getString(Object caller, Locale locale, String key, Object arg0, Object arg1, Object arg2, Object arg3)
+    public static String getString(Object caller, Locale locale, String key, Object arg0,
+                                   Object arg1, Object arg2, Object arg3)
             throws MissingResourceException {
         Object[] o = new Object[4];
         o[0] = arg0;
@@ -612,7 +619,8 @@
      * @param arg3   The argument to place in variable {3}
      * @return Returns the formatted message.
      */
-    public static String getString(Object caller, Locale locale, String key, Object arg0, Object arg1, Object arg2, Object arg3, Object arg4)
+    public static String getString(Object caller, Locale locale, String key, Object arg0,
+                                   Object arg1, Object arg2, Object arg3, Object arg4)
             throws MissingResourceException {
         Object[] o = new Object[5];
         o[0] = arg0;
@@ -629,7 +637,7 @@
      * @param caller The calling object, used to get the package name and class loader
      * @param locale The locale
      * @param key    The resource key
-     * @param args  An array of objects to place in corresponding variables
+     * @param args   An array of objects to place in corresponding variables
      * @return Returns the formatted message.
      */
     public static String getString(Object caller, Locale locale, String key, Object[] args)
@@ -652,7 +660,7 @@
                 curClass = (Class) caller;
             } else {
                 curClass = caller.getClass();
-        }
+            }
         }
 
         while (msg == null) {



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