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 [14/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/transport/http/SOAPMessageFormatter.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/SOAPMessageFormatter.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/SOAPMessageFormatter.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/SOAPMessageFormatter.java Sun Mar  4 10:16:54 2007
@@ -34,10 +34,10 @@
 import java.io.StringWriter;
 import java.net.URL;
 
-public class SOAPMessageFormatter implements MessageFormatter{
+public class SOAPMessageFormatter implements MessageFormatter {
 
     public void writeTo(MessageContext msgCtxt, OMOutputFormat format,
-            OutputStream out, boolean preserve) throws AxisFault {
+                        OutputStream out, boolean preserve) throws AxisFault {
         OMElement element = msgCtxt.getEnvelope();
         try {
             if (!(format.isOptimized()) & format.isDoingSWA()) {
@@ -47,7 +47,7 @@
                 } else {
                     element.serializeAndConsume(bufferedSOAPBody, format);
                 }
-                writeSwAMessage(msgCtxt,bufferedSOAPBody,out,format);
+                writeSwAMessage(msgCtxt, bufferedSOAPBody, out, format);
             } else {
                 if (preserve) {
                     element.serialize(out, format);
@@ -72,7 +72,7 @@
                 if (format.isDoingSWA()) {
                     StringWriter bufferedSOAPBody = new StringWriter();
                     element.serializeAndConsume(bufferedSOAPBody, format2);
-                    writeSwAMessage(msgCtxt,bufferedSOAPBody,bytesOut,format);
+                    writeSwAMessage(msgCtxt, bufferedSOAPBody, bytesOut, format);
                 } else {
                     element.serializeAndConsume(bytesOut, format2);
                 }
@@ -89,7 +89,7 @@
     }
 
     public String getContentType(MessageContext msgCtxt, OMOutputFormat format,
-            String soapActionString) {
+                                 String soapActionString) {
         String encoding = format.getCharSetEncoding();
         String contentType = format.getContentType();
         if (encoding != null) {
@@ -107,7 +107,7 @@
     }
 
     public String formatSOAPAction(MessageContext msgCtxt, OMOutputFormat format,
-            String soapActionString) {
+                                   String soapActionString) {
         // if SOAP 1.2 we attach the soap action to the content-type
         // No need to set it as a header.
         if (msgCtxt.isSOAP11()) {
@@ -115,7 +115,7 @@
                 return "\"\"";
             } else {
                 if (soapActionString != null
-                        && !soapActionString.startsWith("\"")) { 
+                        && !soapActionString.startsWith("\"")) {
                     // SOAPAction string must be a quoted string
                     soapActionString = "\"" + soapActionString + "\"";
                 }
@@ -126,17 +126,17 @@
     }
 
     public URL getTargetAddress(MessageContext msgCtxt, OMOutputFormat format,
-            URL targetURL) throws AxisFault{
+                                URL targetURL) throws AxisFault {
 
         // Check whether there is a template in the URL, if so we have to replace then with data
         // values and create a new target URL.
-        targetURL = URLTemplatingUtil.getTemplatedURL(targetURL,msgCtxt,false);
+        targetURL = URLTemplatingUtil.getTemplatedURL(targetURL, msgCtxt, false);
         return targetURL;
     }
-    
+
     private void writeSwAMessage(MessageContext msgCtxt,
-            StringWriter bufferedSOAPBody, OutputStream outputStream,
-            OMOutputFormat format) {
+                                 StringWriter bufferedSOAPBody, OutputStream outputStream,
+                                 OMOutputFormat format) {
         Object property = msgCtxt
                 .getProperty(Constants.Configuration.MM7_COMPATIBLE);
         boolean MM7CompatMode = false;
@@ -145,7 +145,8 @@
         }
         if (!MM7CompatMode) {
             MIMEOutputUtils.writeSOAPWithAttachmentsMessage(bufferedSOAPBody,
-                    outputStream, msgCtxt.getAttachmentMap(), format);
+                                                            outputStream,
+                                                            msgCtxt.getAttachmentMap(), format);
         } else {
             String innerBoundary;
             String partCID;
@@ -166,8 +167,9 @@
                         + UUIDGenerator.getUUID().replace(':', '_');
             }
             MIMEOutputUtils.writeMM7Message(bufferedSOAPBody, outputStream,
-                    msgCtxt.getAttachmentMap(), format, partCID, innerBoundary);
+                                            msgCtxt.getAttachmentMap(), format, partCID,
+                                            innerBoundary);
         }
     }
-    
+
 }

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/SimpleHTTPServer.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/SimpleHTTPServer.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/SimpleHTTPServer.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/SimpleHTTPServer.java Sun Mar  4 10:16:54 2007
@@ -83,7 +83,8 @@
         this.httpFactory = httpFactory;
         this.configurationContext = httpFactory.getConfigurationContext();
         this.port = httpFactory.getPort();
-        TransportInDescription httpDescription = new TransportInDescription(new QName(Constants.TRANSPORT_HTTP));
+        TransportInDescription httpDescription =
+                new TransportInDescription(new QName(Constants.TRANSPORT_HTTP));
         httpDescription.setReceiver(this);
         httpFactory.getListenerManager().addListener(httpDescription, true);
         sessionManager = new SessionManager();
@@ -141,9 +142,9 @@
         if (paramPort != null) {
             port = Integer.parseInt(paramPort);
         }
-        
+
         boolean startAllTransports = "all".equals(optionsParser.isValueSet('t'));
-        String repository= optionsParser.isValueSet('r');
+        String repository = optionsParser.isValueSet('r');
         if (repository == null) {
             args = optionsParser.getRemainingArgs();
             if (args != null && args[0] != null && args[0] != "") {
@@ -158,7 +159,8 @@
                 + new File(repository).getAbsolutePath());
         System.out.println("[SimpleHTTPServer] Listening on port " + port);
         try {
-            ConfigurationContext configctx = ConfigurationContextFactory.createConfigurationContextFromFileSystem(repository, null);
+            ConfigurationContext configctx = ConfigurationContextFactory
+                    .createConfigurationContextFromFileSystem(repository, null);
             SimpleHTTPServer receiver = new SimpleHTTPServer(configctx, port);
             Runtime.getRuntime().addShutdownHook(new ShutdownThread(receiver));
             receiver.start();
@@ -175,12 +177,12 @@
             // should all transports be started? specified as "-t all"
             if (startAllTransports) {
                 Iterator iter = configctx.getAxisConfiguration().
-                    getTransportsIn().keySet().iterator();
+                        getTransportsIn().keySet().iterator();
                 while (iter.hasNext()) {
                     QName trp = (QName) iter.next();
                     if (!new QName(Constants.TRANSPORT_HTTP).equals(trp)) {
                         trsIn = (TransportInDescription)
-                            configctx.getAxisConfiguration().getTransportsIn().get(trp);
+                                configctx.getAxisConfiguration().getTransportsIn().get(trp);
                         listenerManager.addListener(trsIn, false);
                     }
                 }
@@ -198,7 +200,8 @@
         System.out.println(" Opts: -? this message");
         System.out.println();
         System.out.println("       -p port :to listen on (default is 8080)");
-        System.out.println("       -t all  :to start all transports defined in the axis2 configuration");
+        System.out.println(
+                "       -t all  :to start all transports defined in the axis2 configuration");
         System.exit(1);
     }
 
@@ -248,7 +251,8 @@
         //if host address is present
         if (hostAddress != null) {
             if (embedded != null) {
-                return new EndpointReference[] {new EndpointReference(hostAddress + "/" + configurationContext.getServiceContextPath() + "/" + serviceName)};
+                return new EndpointReference[]{new EndpointReference(hostAddress + "/" +
+                        configurationContext.getServiceContextPath() + "/" + serviceName)};
             } else {
                 throw new AxisFault("Unable to generate EPR for the transport : http");
             }
@@ -268,7 +272,7 @@
             }
         }
         if (embedded != null) {
-            return new EndpointReference[] {new EndpointReference("http://" + localAddress + ":" +
+            return new EndpointReference[]{new EndpointReference("http://" + localAddress + ":" +
                     (embedded.getPort())
                     + "/" + configurationContext.getServiceContextPath() + "/" + serviceName)};
         } else {

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/TransportHeaders.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/TransportHeaders.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/TransportHeaders.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/TransportHeaders.java Sun Mar  4 10:16:54 2007
@@ -110,7 +110,7 @@
 
     public Object get(Object key) {
         if (headerMap == null) {
-            return req.getHeader((String)key);
+            return req.getHeader((String) key);
         }
         return headerMap.get(key);
     }

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/AxisHttpService.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/AxisHttpService.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/AxisHttpService.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/AxisHttpService.java Sun Mar  4 10:16:54 2007
@@ -64,8 +64,8 @@
 import java.util.Iterator;
 
 /**
- * This class is an extension of the defaulf HTTP service responsible for 
- * maintaining and polulating the {@link MessageContext} for incoming Axis 
+ * This class is an extension of the defaulf HTTP service responsible for
+ * maintaining and polulating the {@link MessageContext} for incoming Axis
  * requests.
  */
 public class AxisHttpService extends HttpService {
@@ -76,7 +76,7 @@
     private final ConfigurationContext configurationContext;
     private final SessionManager sessionManager;
     private final Worker worker;
-  
+
     public AxisHttpService(
             final HttpProcessor httpProcessor,
             final ConnectionReuseStrategy connStrategy,
@@ -103,7 +103,7 @@
     }
 
     protected void doService(
-            final HttpRequest request, 
+            final HttpRequest request,
             final HttpResponse response,
             final HttpContext context) throws HttpException, IOException {
         RequestLine reqline = request.getRequestLine();
@@ -127,7 +127,7 @@
             this.msgContext.setTransportIn(transportIn);
             this.msgContext.setTransportOut(transportOut);
             this.msgContext.setServerSide(true);
-            this.msgContext.setProperty(HTTPConstants.COOKIE_STRING,sessionKey);
+            this.msgContext.setProperty(HTTPConstants.COOKIE_STRING, sessionKey);
             this.msgContext.setProperty(Constants.Configuration.TRANSPORT_IN_URL, reqline.getUri());
 
             // set the transport Headers
@@ -149,10 +149,12 @@
                 AxisEngine engine = new AxisEngine(this.configurationContext);
 
                 OutputBuffer outbuffer = new OutputBuffer();
-                this.msgContext.setProperty(MessageContext.TRANSPORT_OUT, outbuffer.getOutputStream());
+                this.msgContext
+                        .setProperty(MessageContext.TRANSPORT_OUT, outbuffer.getOutputStream());
                 this.msgContext.setProperty(Constants.OUT_TRANSPORT_INFO, outbuffer);
 
-                MessageContext faultContext = MessageContextBuilder.createFaultMessageContext(msgContext, e);
+                MessageContext faultContext =
+                        MessageContextBuilder.createFaultMessageContext(msgContext, e);
                 // If the fault is not going along the back channel we should be 202ing
                 if (AddressingHelper.isFaultRedirected(this.msgContext)) {
                     response.setStatusLine(new BasicStatusLine(ver, 202, "Accepted"));
@@ -181,7 +183,7 @@
 
     }
 
-    public void handleRequest(final HttpServerConnection conn, final HttpContext context) 
+    public void handleRequest(final HttpServerConnection conn, final HttpContext context)
             throws IOException, HttpException {
         if (conn instanceof HttpInetConnection) {
             HttpInetConnection inetconn = (HttpInetConnection) conn;

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/AxisParams.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/AxisParams.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/AxisParams.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/AxisParams.java Sun Mar  4 10:16:54 2007
@@ -28,12 +28,12 @@
 package org.apache.axis2.transport.http.server;
 
 public class AxisParams {
-    
+
     private AxisParams() {
     }
 
     public static final String LISTENER_PORT = "axis.listener.port";
-    
+
     public static final String MESSAGE_CONTEXT = "axis.message.context";
-    
+
 }

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/ConnectionListenerFailureHandler.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/ConnectionListenerFailureHandler.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/ConnectionListenerFailureHandler.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/ConnectionListenerFailureHandler.java Sun Mar  4 10:16:54 2007
@@ -30,23 +30,24 @@
 package org.apache.axis2.transport.http.server;
 
 public interface ConnectionListenerFailureHandler {
-    
+
     /**
      * The associated connection listener IOProcessor has failed
      *
      * @param connectionListener the associated connection listener
-     * @param cause cause of failure
+     * @param cause              cause of failure
      * @return true if the listener should attempt to re-establish itself, false if it should terminate.
      */
     public boolean failed(IOProcessor connectionListener, Throwable cause);
-    
+
     /**
      * The associated connection listener IOProcessor is terminating abnormally
      *
      * @param connectionListener the associated connection listener
-     * @param message explanation of termination
-     * @param cause last exception that is causing termination
+     * @param message            explanation of termination
+     * @param cause              last exception that is causing termination
      */
-    public void notifyAbnormalTermination(IOProcessor connectionListener, String message, Throwable cause);
-    
+    public void notifyAbnormalTermination(IOProcessor connectionListener, String message,
+                                          Throwable cause);
+
 }

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/DefaultConnectionListener.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/DefaultConnectionListener.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/DefaultConnectionListener.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/DefaultConnectionListener.java Sun Mar  4 10:16:54 2007
@@ -40,7 +40,7 @@
 public class DefaultConnectionListener implements IOProcessor {
 
     private static Log LOG = LogFactory.getLog(DefaultConnectionListener.class);
-    
+
     private volatile boolean destroyed = false;
 
     private final int port;
@@ -48,20 +48,22 @@
     private final HttpConnectionManager connmanager;
     private ServerSocket serversocket = null;
     private final ConnectionListenerFailureHandler failureHandler;
-    
+
     /**
      * Default constructor called by HttpFactory.  A custom HttpFactory subclass can call the other constructor to provide a custom ConnectionListenerErrorHandler
      */
-    public DefaultConnectionListener(int port, HttpConnectionFactory connfactory, HttpConnectionManager connmanager) throws IOException {
+    public DefaultConnectionListener(int port, HttpConnectionFactory connfactory,
+                                     HttpConnectionManager connmanager) throws IOException {
         this(port, connfactory, connmanager, new DefaultConnectionListenerFailureHandler());
     }
 
     /**
      * Use this constructor to provide a custom ConnectionListenerFailureHandler, e.g. by subclassing DefaultConnectionListenerFailureHandler
      */
-    public DefaultConnectionListener(int port, HttpConnectionFactory connfactory, HttpConnectionManager connmanager,
+    public DefaultConnectionListener(int port, HttpConnectionFactory connfactory,
+                                     HttpConnectionManager connmanager,
                                      ConnectionListenerFailureHandler failureHandler)
-    throws IOException {
+            throws IOException {
         super();
         if (connfactory == null) {
             throw new IllegalArgumentException("Connection factory may not be null");
@@ -82,7 +84,7 @@
         try {
             while (!Thread.interrupted()) {
                 try {
-                    if (serversocket == null || serversocket.isClosed()){
+                    if (serversocket == null || serversocket.isClosed()) {
                         serversocket = new ServerSocket(port);
                         serversocket.setReuseAddress(true);
                         if (LOG.isInfoEnabled()) {
@@ -92,7 +94,7 @@
                     LOG.debug("Waiting for incoming HTTP connection");
                     Socket socket = this.serversocket.accept();
                     if (LOG.isDebugEnabled()) {
-                        LOG.debug("Incoming HTTP connection from " + 
+                        LOG.debug("Incoming HTTP connection from " +
                                 socket.getRemoteSocketAddress());
                     }
                     HttpServerConnection conn = this.connfactory.newConnection(socket);
@@ -103,20 +105,20 @@
                     }
                     if (!failureHandler.failed(this, ex)) {
                         break;
+                    }
                 }
             }
-            }
         } finally {
             destroy();
         }
     }
-    
+
     public void close() throws IOException {
-        if(this.serversocket != null){
+        if (this.serversocket != null) {
             this.serversocket.close();
         }
     }
-    
+
     public void destroy() {
         this.destroyed = true;
         try {
@@ -131,5 +133,5 @@
     public boolean isDestroyed() {
         return this.destroyed;
     }
-    
+
 }

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/DefaultConnectionListenerFailureHandler.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/DefaultConnectionListenerFailureHandler.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/DefaultConnectionListenerFailureHandler.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/DefaultConnectionListenerFailureHandler.java Sun Mar  4 10:16:54 2007
@@ -34,20 +34,20 @@
 
 /**
  * Default hander for failures in connection listener IOProcessors.
- *  Supports configuration of number retries, delay per retry, and uptime interval considered a success (resets number retries to zero).
+ * Supports configuration of number retries, delay per retry, and uptime interval considered a success (resets number retries to zero).
  */
 public class DefaultConnectionListenerFailureHandler implements ConnectionListenerFailureHandler {
-    
+
     private static final Log LOG = LogFactory.getLog(DefaultConnectionListenerFailureHandler.class);
 
     protected int retryDelay;
     protected int successInterval;
     protected int maxRetries;
-    
+
     private long lastFailure;
     private long lastFirstFailure;
     private int numRetries;
-    
+
     /**
      * Create a new DefaultConnectionListenerFailureHandler with default settings.
      * retryDelay is 1 second, successInterval is 60 seconds, maxRetries is 10
@@ -59,11 +59,12 @@
     /**
      * Create a new DefaultConnectionListenerFailureHandler
      *
-     * @param retryDelay millis to wait before retrying
+     * @param retryDelay      millis to wait before retrying
      * @param successInterval millis after which an initial or retry attempt will be deemed a success, resetting retry count to 0
-     * @param maxRetries maximum number of retries allowed without a success, after which the listener will terminate
+     * @param maxRetries      maximum number of retries allowed without a success, after which the listener will terminate
      */
-    public DefaultConnectionListenerFailureHandler(int retryDelay, int successInterval, int maxRetries) {
+    public DefaultConnectionListenerFailureHandler(int retryDelay, int successInterval,
+                                                   int maxRetries) {
         this.retryDelay = retryDelay;
         this.successInterval = successInterval;
         this.maxRetries = maxRetries;
@@ -77,7 +78,7 @@
      */
     public boolean failed(IOProcessor connectionListener, Throwable cause) {
         long now = System.currentTimeMillis();
-        if (now > lastFailure+successInterval) {
+        if (now > lastFailure + successInterval) {
             numRetries = 0;
             lastFirstFailure = now;
         }
@@ -85,13 +86,17 @@
         if (numRetries >= maxRetries) {
             notifyAbnormalTermination(
                     connectionListener,
-                    "Terminating connection listener " + connectionListener + " after " + numRetries + "retries in " + (now-lastFirstFailure)/1000 + " seconds.",
+                    "Terminating connection listener " + connectionListener + " after " +
+                            numRetries + "retries in " + (now - lastFirstFailure) / 1000 +
+                            " seconds.",
                     cause);
             return false;
         } else {
             numRetries++;
             if (LOG.isWarnEnabled()) {
-                LOG.warn("Attempt number " + numRetries + " of " + maxRetries + " to reestalish connection listener " + connectionListener + " due to failure ",
+                LOG.warn("Attempt number " + numRetries + " of " + maxRetries +
+                        " to reestalish connection listener " + connectionListener +
+                        " due to failure ",
                          cause);
             }
             return true;
@@ -102,8 +107,9 @@
      * Default bevarior is to log the error.
      * May subclass and override this method to change behavior.
      */
-    public void notifyAbnormalTermination(IOProcessor connectionListener, String message, Throwable cause) {
+    public void notifyAbnormalTermination(IOProcessor connectionListener, String message,
+                                          Throwable cause) {
         LOG.error(message, cause);
     }
-    
+
 }

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/DefaultHttpConnectionFactory.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/DefaultHttpConnectionFactory.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/DefaultHttpConnectionFactory.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/DefaultHttpConnectionFactory.java Sun Mar  4 10:16:54 2007
@@ -39,7 +39,7 @@
 public class DefaultHttpConnectionFactory implements HttpConnectionFactory {
 
     final HttpParams params;
-    
+
     public DefaultHttpConnectionFactory(final HttpParams params) {
         super();
         if (params == null) {
@@ -47,14 +47,14 @@
         }
         this.params = params;
     }
-    
+
     public HttpServerConnection newConnection(final Socket socket)
             throws IOException {
         DefaultHttpServerConnection conn = new Axis2HttpServerConnection();
         conn.bind(socket, this.params);
         return conn;
     }
-    
+
     public class Axis2HttpServerConnection extends DefaultHttpServerConnection {
         public Axis2HttpServerConnection() {
             super();
@@ -72,10 +72,11 @@
         public String getRemoteHostName() {
             java.net.SocketAddress sa = socket.getRemoteSocketAddress();
             if (sa instanceof java.net.InetSocketAddress) {
-              return ((java.net.InetSocketAddress) sa).getHostName();
-          } else {
-              return sa.toString(); // fail-safe and fall back to something which one can use in place of the host name
-          }
+                return ((java.net.InetSocketAddress) sa).getHostName();
+            } else {
+                return sa
+                        .toString(); // fail-safe and fall back to something which one can use in place of the host name
+            }
         }
     }
 

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/DefaultHttpConnectionManager.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/DefaultHttpConnectionManager.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/DefaultHttpConnectionManager.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/DefaultHttpConnectionManager.java Sun Mar  4 10:16:54 2007
@@ -53,16 +53,16 @@
 public class DefaultHttpConnectionManager implements HttpConnectionManager {
 
     private static Log LOG = LogFactory.getLog(DefaultHttpConnectionManager.class);
-    
+
     private final ConfigurationContext configurationContext;
     private final Executor executor;
     private final WorkerFactory workerfactory;
     private final HttpParams params;
     private final List processors;
     private final SessionManager sessionManager;
-    
+
     private HttpFactory httpFactory = null;
-    
+
     public DefaultHttpConnectionManager(
             final ConfigurationContext configurationContext,
             final Executor executor,
@@ -88,12 +88,12 @@
         this.params = params;
         this.processors = new LinkedList();
     }
-    
+
     public DefaultHttpConnectionManager(
             final ConfigurationContext configurationContext,
             final Executor executor,
             final WorkerFactory workerfactory,
-            final HttpParams params, 
+            final HttpParams params,
             final HttpFactory httpFactory) {
         this(configurationContext, executor, workerfactory, params);
         this.httpFactory = httpFactory;
@@ -101,42 +101,42 @@
 
 
     private synchronized void cleanup() {
-        for (Iterator i = this.processors.iterator(); i.hasNext(); ) {
+        for (Iterator i = this.processors.iterator(); i.hasNext();) {
             IOProcessor processor = (IOProcessor) i.next();
             if (processor.isDestroyed()) {
                 i.remove();
             }
         }
     }
-    
+
     private synchronized void addProcessor(final IOProcessor processor) {
         if (processor == null) {
             return;
         }
         this.processors.add(processor);
     }
-    
+
     private synchronized void removeProcessor(final IOProcessor processor) {
         if (processor == null) {
             return;
         }
         this.processors.remove(processor);
     }
-    
+
     public void process(final HttpServerConnection conn) {
         if (conn == null) {
             throw new IllegalArgumentException("HTTP connection may not be null");
         }
         // Evict destroyed processors
         cleanup();
-        
+
         // Assemble new Axis HTTP service
         HttpProcessor httpProcessor;
         ConnectionReuseStrategy connStrategy;
         HttpResponseFactory responseFactory;
-        
+
         if (httpFactory != null) {
-            httpProcessor = httpFactory.newHttpProcessor(); 
+            httpProcessor = httpFactory.newHttpProcessor();
             connStrategy = httpFactory.newConnStrategy();
             responseFactory = httpFactory.newResponseFactory();
         } else {
@@ -147,7 +147,7 @@
             p.addInterceptor(new ResponseContent());
             p.addInterceptor(new ResponseConnControl());
             p.addInterceptor(new ResponseSessionCookie());
-            httpProcessor =  new LoggingProcessorDecorator(p);
+            httpProcessor = new LoggingProcessorDecorator(p);
             connStrategy = new DefaultConnectionReuseStrategy();
             responseFactory = new DefaultHttpResponseFactory();
         }
@@ -160,17 +160,17 @@
                 this.sessionManager,
                 this.workerfactory.newWorker());
         httpService.setParams(this.params);
-        
+
         // Create I/O processor to execute HTTP service
         IOProcessorCallback callback = new IOProcessorCallback() {
-          
+
             public void completed(final IOProcessor processor) {
                 removeProcessor(processor);
                 if (LOG.isDebugEnabled()) {
                     LOG.debug(processor + " terminated");
                 }
             }
-            
+
         };
         IOProcessor processor = new HttpServiceProcessor(
                 httpService,
@@ -180,7 +180,7 @@
         addProcessor(processor);
         this.executor.execute(processor);
     }
-    
+
     public synchronized void shutdown() {
         for (int i = 0; i < this.processors.size(); i++) {
             IOProcessor processor = (IOProcessor) this.processors.get(i);
@@ -188,5 +188,5 @@
         }
         this.processors.clear();
     }
-    
+
 }

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/DefaultThreadFactory.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/DefaultThreadFactory.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/DefaultThreadFactory.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/DefaultThreadFactory.java Sun Mar  4 10:16:54 2007
@@ -36,7 +36,7 @@
     final ThreadGroup group;
     final AtomicInteger count;
     final String namePrefix;
-    
+
     public DefaultThreadFactory(final ThreadGroup group, final String namePrefix) {
         super();
         this.count = new AtomicInteger(1);
@@ -54,5 +54,5 @@
         t.setPriority(Thread.NORM_PRIORITY);
         return t;
     }
-        
+
 }

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/HttpConnectionFactory.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/HttpConnectionFactory.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/HttpConnectionFactory.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/HttpConnectionFactory.java Sun Mar  4 10:16:54 2007
@@ -37,5 +37,5 @@
 public interface HttpConnectionFactory {
 
     HttpServerConnection newConnection(Socket socket) throws IOException;
-    
+
 }

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/HttpConnectionManager.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/HttpConnectionManager.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/HttpConnectionManager.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/HttpConnectionManager.java Sun Mar  4 10:16:54 2007
@@ -34,7 +34,7 @@
 public interface HttpConnectionManager {
 
     void process(HttpServerConnection incoming);
-    
+
     void shutdown();
-    
+
 }

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/HttpFactory.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/HttpFactory.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/HttpFactory.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/HttpFactory.java Sun Mar  4 10:16:54 2007
@@ -71,7 +71,7 @@
      * Name of axis2.xml port parameter for SimpleHTTPServer configuration
      */
     public static final String PARAMETER_PORT = "port";
-    
+
     /**
      * Name of axis2.xml hostname parameter for SimpleHTTPServer configuration
      */
@@ -95,7 +95,8 @@
     /**
      * Name of axis2.xml requestCoreThreadPoolSize parameter for SimpleHTTPServer configuration
      */
-    public static final String PARAMETER_REQUEST_CORE_THREAD_POOL_SIZE = "requestCoreThreadPoolSize";
+    public static final String PARAMETER_REQUEST_CORE_THREAD_POOL_SIZE =
+            "requestCoreThreadPoolSize";
 
     /**
      * Name of axis2.xml requestMaxThreadPoolSize parameter for SimpleHTTPServer configuration
@@ -111,7 +112,7 @@
      * Name of axis2.xml threadKeepAliveTimeUnit parameter for SimpleHTTPServer configuration
      */
     public static final String PARAMETER_THREAD_KEEP_ALIVE_TIME_UNIT = "threadKeepAliveTimeUnit";
-    
+
     private ConfigurationContext configurationContext;
     private TransportInDescription httpConfiguration;
     private int port;
@@ -123,11 +124,11 @@
     private int requestMaxThreadPoolSize;
     private long threadKeepAliveTime;
     private TimeUnit threadKeepAliveTimeUnit;
-    
+
     private WorkerFactory requestWorkerFactory = null;
-    
+
     private static final QName HTTP_NAME = new QName(Constants.TRANSPORT_HTTP);
-    
+
     /**
      * Create and configure a new HttpFactory
      */
@@ -142,9 +143,10 @@
         requestCoreThreadPoolSize = getIntParam(PARAMETER_REQUEST_CORE_THREAD_POOL_SIZE, 25);
         requestMaxThreadPoolSize = getIntParam(PARAMETER_REQUEST_MAX_THREAD_POOL_SIZE, 150);
         threadKeepAliveTime = getLongParam(PARAMETER_THREAD_KEEP_ALIVE_TIME, 180L);
-        threadKeepAliveTimeUnit = getTimeUnitParam(PARAMETER_THREAD_KEEP_ALIVE_TIME_UNIT, TimeUnit.SECONDS);
+        threadKeepAliveTimeUnit =
+                getTimeUnitParam(PARAMETER_THREAD_KEEP_ALIVE_TIME_UNIT, TimeUnit.SECONDS);
     }
-    
+
     /**
      * Create and configure a new HttpFactory
      */
@@ -152,11 +154,12 @@
         this(configurationContext);
         this.port = port;
     }
-    
+
     /**
      * Create and configure a new HttpFactory
      */
-    public HttpFactory(ConfigurationContext configurationContext, int port, WorkerFactory requestWorkerFactory) throws AxisFault {
+    public HttpFactory(ConfigurationContext configurationContext, int port,
+                       WorkerFactory requestWorkerFactory) throws AxisFault {
         this(configurationContext, port);
         this.requestWorkerFactory = requestWorkerFactory;
     }
@@ -167,32 +170,33 @@
             return Integer.parseInt(config);
         } else {
             return def;
+        }
     }
-    }
-    
+
     private long getLongParam(String name, long def) {
         String config = getStringParam(name, null);
         if (config != null) {
             return Long.parseLong(config);
         } else {
             return def;
+        }
     }
-    }
-    
+
     private boolean getBooleanParam(String name, boolean def) throws AxisFault {
         String config = getStringParam(name, null);
-        if (config!=null) {
+        if (config != null) {
             if (config.equals("yes") || config.equals("true")) {
                 return true;
             } else if (config.equals("no") || config.equals("false")) {
                 return false;
             } else {
-                throw new AxisFault("Boolean value must be yes, true, no or false for parameter " + name + ":  " + config);
+                throw new AxisFault("Boolean value must be yes, true, no or false for parameter " +
+                        name + ":  " + config);
             }
         }
         return def;
     }
-    
+
     private TimeUnit getTimeUnitParam(String name, TimeUnit def) throws AxisFault {
         String config = getStringParam(name, null);
         if (config != null) {
@@ -204,84 +208,94 @@
         }
         return def;
     }
-        
+
     private String getStringParam(String name, String def) {
         Parameter param = httpConfiguration.getParameter(name);
-        if (param!=null) {
+        if (param != null) {
 //            assert param.getParameterType() == Parameter.TEXT_PARAMETER;
             String config = (String) param.getValue();
             if (config != null) {
                 return config;
-        }
+            }
         }
         return def;
     }
-    
+
     /**
      * Return the configured listener manager or create and configure one with configurationContext
      */
     public ListenerManager getListenerManager() {
         ListenerManager lm = configurationContext.getListenerManager();
-        if (lm==null) {
+        if (lm == null) {
             lm = new ListenerManager();
             lm.init(configurationContext);
         }
         return lm;
     }
-    
+
     /**
      * Create the executor used to launch the single requestConnectionListener
      */
     public ExecutorService newListenerExecutor(int port) {
         return new ThreadPoolExecutor(1, 1, 0L, TimeUnit.MILLISECONDS,
-                new LinkedBlockingQueue(),
-                new DefaultThreadFactory(new ThreadGroup("Listener thread group"), "HttpListener-" + this.port));
+                                      new LinkedBlockingQueue(),
+                                      new DefaultThreadFactory(
+                                              new ThreadGroup("Listener thread group"),
+                                              "HttpListener-" + this.port));
     }
-    
+
     /**
      * Create the listener for request connections
      */
-    public IOProcessor newRequestConnectionListener(HttpConnectionFactory factory, HttpConnectionManager manager, int port) throws IOException {
+    public IOProcessor newRequestConnectionListener(HttpConnectionFactory factory,
+                                                    HttpConnectionManager manager, int port)
+            throws IOException {
         return new DefaultConnectionListener(port, factory, manager);
     }
-    
+
     /**
      * Create a request connection
      */
     public HttpConnectionFactory newRequestConnectionFactory(HttpParams params) {
         return new DefaultHttpConnectionFactory(params);
     }
-    
+
     /**
      * Create and set the parameters applied to incoming request connections
      */
     public HttpParams newRequestConnectionParams() {
-        HttpParams params = new DefaultHttpParams(); 
+        HttpParams params = new DefaultHttpParams();
         params
-            .setIntParameter(HttpConnectionParams.SO_TIMEOUT, requestSocketTimeout)
-            .setBooleanParameter(HttpConnectionParams.TCP_NODELAY, requestTcpNoDelay) 
-            .setIntParameter(HttpConnectionParams.MAX_LINE_LENGTH, 4000)
-            .setIntParameter(HttpConnectionParams.MAX_HEADER_COUNT, 500)
-            .setParameter(HttpProtocolParams.ORIGIN_SERVER, originServer);
+                .setIntParameter(HttpConnectionParams.SO_TIMEOUT, requestSocketTimeout)
+                .setBooleanParameter(HttpConnectionParams.TCP_NODELAY, requestTcpNoDelay)
+                .setIntParameter(HttpConnectionParams.MAX_LINE_LENGTH, 4000)
+                .setIntParameter(HttpConnectionParams.MAX_HEADER_COUNT, 500)
+                .setParameter(HttpProtocolParams.ORIGIN_SERVER, originServer);
         return params;
     }
-    
+
     /**
      * Create the connection manager used to launch request threads
      */
-    public HttpConnectionManager newRequestConnectionManager(ExecutorService requestExecutor, WorkerFactory workerFactory, HttpParams params) {
-        return new DefaultHttpConnectionManager(configurationContext, requestExecutor, workerFactory, params);
+    public HttpConnectionManager newRequestConnectionManager(ExecutorService requestExecutor,
+                                                             WorkerFactory workerFactory,
+                                                             HttpParams params) {
+        return new DefaultHttpConnectionManager(configurationContext, requestExecutor,
+                                                workerFactory, params);
     }
-    
+
     /**
      * Create the executor use the manage request processing threads
      */
     public ExecutorService newRequestExecutor(int port) {
-        return new ThreadPoolExecutor(requestCoreThreadPoolSize, requestMaxThreadPoolSize, threadKeepAliveTime, threadKeepAliveTimeUnit,
+        return new ThreadPoolExecutor(requestCoreThreadPoolSize, requestMaxThreadPoolSize,
+                                      threadKeepAliveTime, threadKeepAliveTimeUnit,
                                       newRequestBlockingQueue(),
-                                      new DefaultThreadFactory(new ThreadGroup("Connection thread group"), "HttpConnection-" + port));
+                                      new DefaultThreadFactory(
+                                              new ThreadGroup("Connection thread group"),
+                                              "HttpConnection-" + port));
     }
-    
+
     /**
      * Create the queue used to hold incoming requests when requestCoreThreadPoolSize threads are busy.
      * Default is an unbounded queue.
@@ -289,7 +303,7 @@
     public BlockingQueue newRequestBlockingQueue() {
         return new LinkedBlockingQueue();
     }
-    
+
     /**
      * Create the factory for request workers
      */
@@ -298,7 +312,7 @@
             return requestWorkerFactory;
         } else {
             return new HTTPWorkerFactory();
-    }
+        }
     }
 
     public HttpProcessor newHttpProcessor() {
@@ -315,11 +329,11 @@
     public ConnectionReuseStrategy newConnStrategy() {
         return new DefaultConnectionReuseStrategy();
     }
-    
+
     public HttpResponseFactory newResponseFactory() {
         return new DefaultHttpResponseFactory();
     }
-    
+
     // *****
     // Getters and Setters
     // *****
@@ -340,7 +354,7 @@
 
     /**
      * Getter for port
-      * return the port on which to listen for http connections (default = 6060)
+     * return the port on which to listen for http connections (default = 6060)
      */
     public int getPort() {
         return port;
@@ -404,8 +418,8 @@
     /**
      * Getter for requestTcpNoDelay
      * return false iff Nagle's algorithm should be used to conserve bandwidth by minimizing segments
-     *              at the cost of latency and performance (default true, i.e. maximize performance at
-     *              the cost of bandwidth)
+     * at the cost of latency and performance (default true, i.e. maximize performance at
+     * the cost of bandwidth)
      */
     public boolean getRequestTcpNoDelay() {
         return requestTcpNoDelay;

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/HttpServiceProcessor.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/HttpServiceProcessor.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/HttpServiceProcessor.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/HttpServiceProcessor.java Sun Mar  4 10:16:54 2007
@@ -44,21 +44,21 @@
 
 /**
  * I/O processor intended to process requests and fill in responses.
- * 
+ *
  * @author Chuck Williams
  */
 public class HttpServiceProcessor implements IOProcessor {
 
     private static final Log LOG = LogFactory.getLog(HttpServiceProcessor.class);
-    
+
     private volatile boolean terminated;
-    
+
     private final HttpService httpservice;
     private final HttpServerConnection conn;
     private final IOProcessorCallback callback;
-    
+
     public HttpServiceProcessor(
-            final HttpService httpservice, 
+            final HttpService httpservice,
             final HttpServerConnection conn,
             final IOProcessorCallback callback) {
         super();
@@ -67,7 +67,7 @@
         this.callback = callback;
         this.terminated = false;
     }
-    
+
     public void run() {
         LOG.debug("New connection thread");
         HttpContext context = new HttpExecutionContext(null);

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/HttpUtils.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/HttpUtils.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/HttpUtils.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/HttpUtils.java Sun Mar  4 10:16:54 2007
@@ -84,7 +84,7 @@
             }
         }
 
-        return address;                                                     
+        return address;
     }
 
     private static boolean isIP(String hostAddress) {

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/IOProcessor.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/IOProcessor.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/IOProcessor.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/IOProcessor.java Sun Mar  4 10:16:54 2007
@@ -34,9 +34,9 @@
 public interface IOProcessor extends Runnable {
 
     void close() throws IOException;
-    
+
     boolean isDestroyed();
-    
+
     void destroy();
-    
+
 }

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/IOProcessorCallback.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/IOProcessorCallback.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/IOProcessorCallback.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/IOProcessorCallback.java Sun Mar  4 10:16:54 2007
@@ -32,5 +32,5 @@
 public interface IOProcessorCallback {
 
     void completed(IOProcessor processor);
-    
+
 }

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/LoggingProcessorDecorator.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/LoggingProcessorDecorator.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/LoggingProcessorDecorator.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/LoggingProcessorDecorator.java Sun Mar  4 10:16:54 2007
@@ -39,15 +39,16 @@
 import java.io.IOException;
 
 /**
- * This class wraps an arbitrary {@link HttpProcessor} and extends it with 
+ * This class wraps an arbitrary {@link HttpProcessor} and extends it with
  * an additional request / response debugging service
  */
 public class LoggingProcessorDecorator implements HttpProcessor {
-    
-    private static final Log HEADERLOG = LogFactory.getLog("org.apache.axis2.transport.http.server.wire");
-    
+
+    private static final Log HEADERLOG =
+            LogFactory.getLog("org.apache.axis2.transport.http.server.wire");
+
     final private HttpProcessor httpProcessor;
-    
+
     public LoggingProcessorDecorator(final HttpProcessor httpProcessor) {
         super();
         if (httpProcessor == null) {
@@ -56,7 +57,7 @@
         this.httpProcessor = httpProcessor;
     }
 
-    public void process(final HttpRequest request, final HttpContext context) 
+    public void process(final HttpRequest request, final HttpContext context)
             throws HttpException, IOException {
         this.httpProcessor.process(request, context);
         if (HEADERLOG.isDebugEnabled()) {
@@ -68,7 +69,7 @@
         }
     }
 
-    public void process(final HttpResponse response, final HttpContext context) 
+    public void process(final HttpResponse response, final HttpContext context)
             throws HttpException, IOException {
         this.httpProcessor.process(response, context);
         if (HEADERLOG.isDebugEnabled()) {

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/OutputBuffer.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/OutputBuffer.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/OutputBuffer.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/OutputBuffer.java Sun Mar  4 10:16:54 2007
@@ -44,13 +44,13 @@
     private final ByteArrayBuffer buffer;
     private String contentType;
     private boolean chunked;
-    
+
     public OutputBuffer(int initialCapacity) {
         super();
         this.buffer = new ByteArrayBuffer(initialCapacity);
         this.contentType = "text/xml";
     }
-    
+
     public OutputBuffer() {
         this(1024);
     }
@@ -105,7 +105,7 @@
     public String toString() {
         return new String(this.buffer.buffer(), 0, this.buffer.length());
     }
-    
+
     private static class BufferOutputStream extends OutputStream {
 
         private final ByteArrayBuffer buffer;
@@ -115,7 +115,7 @@
             super();
             this.buffer = buffer;
         }
-        
+
         public void close() throws IOException {
             this.closed = true;
         }
@@ -125,7 +125,7 @@
                 throw new IllegalStateException("Stream closed");
             }
         }
-        
+
         public void write(byte[] b, int off, int len) throws IOException {
             ensureNotClosed();
             if (b == null) {
@@ -146,7 +146,7 @@
             ensureNotClosed();
             this.buffer.append(b);
         }
-                
+
     }
-    
+
 }

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/RequestSessionCookie.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/RequestSessionCookie.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/RequestSessionCookie.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/RequestSessionCookie.java Sun Mar  4 10:16:54 2007
@@ -42,7 +42,7 @@
 
 public class RequestSessionCookie implements HttpRequestInterceptor {
 
-    public void process(final HttpRequest request, final HttpContext context) 
+    public void process(final HttpRequest request, final HttpContext context)
             throws HttpException, IOException {
         if (request == null) {
             throw new IllegalArgumentException("HTTP request may not be null");
@@ -50,14 +50,14 @@
         if (context == null) {
             throw new IllegalArgumentException("HTTP context may not be null");
         }
-        
+
         String sessionCookie = null;
         Header[] headers = request.getHeaders(HTTPConstants.HEADER_COOKIE);
         for (int i = 0; i < headers.length; i++) {
             HeaderElement[] elements = headers[i].getElements();
             for (int e = 0; e < elements.length; e++) {
                 HeaderElement element = elements[e];
-                if (Constants.SESSION_COOKIE.equalsIgnoreCase(element.getName())||
+                if (Constants.SESSION_COOKIE.equalsIgnoreCase(element.getName()) ||
                         Constants.SESSION_COOKIE_JSESSIONID.equalsIgnoreCase(element.getName())) {
                     sessionCookie = element.getValue();
                 }
@@ -65,5 +65,5 @@
         }
         context.setAttribute(HTTPConstants.COOKIE_STRING, sessionCookie);
     }
-    
+
 }

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/ResponseSessionCookie.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/ResponseSessionCookie.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/ResponseSessionCookie.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/ResponseSessionCookie.java Sun Mar  4 10:16:54 2007
@@ -43,7 +43,7 @@
 
 public class ResponseSessionCookie implements HttpResponseInterceptor {
 
-    public void process(final HttpResponse response, final HttpContext context) 
+    public void process(final HttpResponse response, final HttpContext context)
             throws HttpException, IOException {
         if (response == null) {
             throw new IllegalArgumentException("HTTP response may not be null");
@@ -51,14 +51,14 @@
         if (context == null) {
             throw new IllegalArgumentException("HTTP context may not be null");
         }
-        
+
         String sessionCookie = null;
         MessageContext msgctx = (MessageContext) context.getAttribute(AxisParams.MESSAGE_CONTEXT);
         if (msgctx != null) {
             sessionCookie = (String) msgctx.getProperty(HTTPConstants.COOKIE_STRING);
         }
         if (sessionCookie == null) {
-          sessionCookie = (String) context.getAttribute(HTTPConstants.COOKIE_STRING);
+            sessionCookie = (String) context.getAttribute(HTTPConstants.COOKIE_STRING);
         }
         if (sessionCookie != null) {
             // Generate Netscape style cookie header
@@ -69,7 +69,7 @@
             buffer1.append("=");
             buffer1.append(sessionCookie);
             response.addHeader(new BufferedHeader(buffer1));
-            
+
             // Generate RFC2965 cookie2 header
             CharArrayBuffer buffer2 = new CharArrayBuffer(sessionCookie.length() + 50);
             buffer2.append(HTTPConstants.HEADER_SET_COOKIE2);
@@ -88,5 +88,5 @@
             response.addHeader(new BufferedHeader(buffer2));
         }
     }
-    
+
 }

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/SessionManager.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/SessionManager.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/SessionManager.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/SessionManager.java Sun Mar  4 10:16:54 2007
@@ -42,12 +42,12 @@
 public class SessionManager {
 
     private final Map sessionmap;
-    
+
     public SessionManager() {
         super();
         this.sessionmap = new HashMap();
     }
-    
+
     public synchronized SessionContext getSessionContext(String sessionKey) {
         SessionContext sessionContext = null;
         if (sessionKey != null && sessionKey.length() != 0) {
@@ -66,7 +66,7 @@
 
     private void cleanupServiceGroupContexts() {
         long currentTime = System.currentTimeMillis();
-        for (Iterator it = this.sessionmap.keySet().iterator(); it.hasNext(); ) {
+        for (Iterator it = this.sessionmap.keySet().iterator(); it.hasNext();) {
             String cookieID = (String) it.next();
             SessionContext sessionContext = (SessionContext) this.sessionmap.get(cookieID);
             if ((currentTime - sessionContext.getLastTouchedTime()) >
@@ -75,7 +75,8 @@
                 Iterator serviceGroupContext = sessionContext.getServiceGroupContext();
                 if (serviceGroupContext != null) {
                     while (serviceGroupContext.hasNext()) {
-                        ServiceGroupContext groupContext = (ServiceGroupContext) serviceGroupContext.next();
+                        ServiceGroupContext groupContext =
+                                (ServiceGroupContext) serviceGroupContext.next();
                         cleanupServiceContexts(groupContext);
                     }
                 }
@@ -84,10 +85,10 @@
     }
 
     private void cleanupServiceContexts(final ServiceGroupContext serviceGroupContext) {
-        for (Iterator it = serviceGroupContext.getServiceContexts(); it.hasNext(); ) {
+        for (Iterator it = serviceGroupContext.getServiceContexts(); it.hasNext();) {
             ServiceContext serviceContext = (ServiceContext) it.next();
             DependencyManager.destroyServiceObject(serviceContext);
         }
     }
-    
+
 }

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/SimpleHttpServer.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/SimpleHttpServer.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/SimpleHttpServer.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/SimpleHttpServer.java Sun Mar  4 10:16:54 2007
@@ -45,24 +45,25 @@
 public class SimpleHttpServer {
 
     private static Log LOG = LogFactory.getLog(SimpleHttpServer.class);
-    
+
     private static final int SHUTDOWN_GRACE_PERIOD = 3000; // ms
-    
+
     private HttpFactory httpFactory;
     private final int port;
     private final HttpParams params;
     private final WorkerFactory workerFactory;
-    
+
     private IOProcessor listener = null;
     private ExecutorService listenerExecutor = null;
     private HttpConnectionManager connmanager = null;
     private HttpConnectionFactory connfactory = null;
     private ExecutorService requestExecutor = null;
 
-    public SimpleHttpServer(ConfigurationContext configurationContext, WorkerFactory workerFactory, int port) throws IOException {
+    public SimpleHttpServer(ConfigurationContext configurationContext, WorkerFactory workerFactory,
+                            int port) throws IOException {
         this(new HttpFactory(configurationContext, port, workerFactory), port);
     }
-    
+
     public SimpleHttpServer(HttpFactory httpFactory, int port) throws IOException {
         this.httpFactory = httpFactory;
         this.port = port;
@@ -73,12 +74,13 @@
 
     public void init() throws IOException {
         requestExecutor = httpFactory.newRequestExecutor(port);
-        connmanager = httpFactory.newRequestConnectionManager(requestExecutor, workerFactory, params);
+        connmanager =
+                httpFactory.newRequestConnectionManager(requestExecutor, workerFactory, params);
         listenerExecutor = httpFactory.newListenerExecutor(port);
         connfactory = httpFactory.newRequestConnectionFactory(params);
         listener = httpFactory.newRequestConnectionListener(connfactory, connmanager, port);
     }
-    
+
     public void destroy() throws IOException, InterruptedException {
         // Attempt to terminate the listener nicely
         LOG.info("Shut down connection listener");
@@ -105,11 +107,11 @@
         }
         LOG.info("HTTP protocol handler shut down");
     }
-    
+
     public void start() {
         this.listenerExecutor.execute(this.listener);
     }
-    
+
     public boolean isRunning() {
         return this.listenerExecutor != null && !this.listenerExecutor.isShutdown();
     }
@@ -117,5 +119,5 @@
     public int getPort() {
         return this.port;
     }
-    
+
 }

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/Worker.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/Worker.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/Worker.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/Worker.java Sun Mar  4 10:16:54 2007
@@ -36,7 +36,7 @@
 
 public interface Worker {
 
-    void service(HttpRequest request, HttpResponse response, MessageContext msgContext) 
-        throws HttpException, IOException;    
-    
+    void service(HttpRequest request, HttpResponse response, MessageContext msgContext)
+            throws HttpException, IOException;
+
 }

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/WorkerFactory.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/WorkerFactory.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/WorkerFactory.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/server/WorkerFactory.java Sun Mar  4 10:16:54 2007
@@ -29,6 +29,6 @@
 
 public interface WorkerFactory {
 
-    Worker newWorker();    
-    
+    Worker newWorker();
+
 }

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/util/ComplexPart.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/util/ComplexPart.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/util/ComplexPart.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/util/ComplexPart.java Sun Mar  4 10:16:54 2007
@@ -51,18 +51,18 @@
     /**
      * Constructor.
      *
-     * @param name The name of the part
-     * @param value the string to post
+     * @param name    The name of the part
+     * @param value   the string to post
      * @param charset the charset to be used to encode the string, if <code>null</code>
-     * the {@link #DEFAULT_CHARSET default} is used
+     *                the {@link #DEFAULT_CHARSET default} is used
      */
     public ComplexPart(String name, String value, String charset) {
 
         super(
-            name,
-            DEFAULT_CONTENT_TYPE,
-            charset == null ? DEFAULT_CHARSET : charset,
-            DEFAULT_TRANSFER_ENCODING
+                name,
+                DEFAULT_CONTENT_TYPE,
+                charset == null ? DEFAULT_CHARSET : charset,
+                DEFAULT_TRANSFER_ENCODING
         );
         if (value == null) {
             throw new IllegalArgumentException("Value may not be null");
@@ -77,7 +77,7 @@
     /**
      * Constructor.
      *
-     * @param name The name of the part
+     * @param name  The name of the part
      * @param value the string to post
      */
     public ComplexPart(String name, String value) {

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/util/RESTUtil.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/util/RESTUtil.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/util/RESTUtil.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/util/RESTUtil.java Sun Mar  4 10:16:54 2007
@@ -68,9 +68,9 @@
             throw new AxisFault(e);
         } catch (IOException e) {
             throw new AxisFault(e);
-        } finally{
+        } finally {
             msgContext.setProperty(Constants.Configuration.MESSAGE_TYPE,
-                                               HTTPConstants.MEDIA_TYPE_APPLICATION_XML);
+                                   HTTPConstants.MEDIA_TYPE_APPLICATION_XML);
         }
         return invokeAxisEngine(msgContext);
     }
@@ -109,9 +109,9 @@
         }
         catch (IOException e) {
             throw new AxisFault(e);
-        } finally{
+        } finally {
             msgContext.setProperty(Constants.Configuration.MESSAGE_TYPE,
-                                               HTTPConstants.MEDIA_TYPE_APPLICATION_XML);
+                                   HTTPConstants.MEDIA_TYPE_APPLICATION_XML);
         }
         return invokeAxisEngine(msgContext);
     }

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/util/SOAPUtil.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/util/SOAPUtil.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/util/SOAPUtil.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/util/SOAPUtil.java Sun Mar  4 10:16:54 2007
@@ -33,7 +33,7 @@
 
 /**
  * @deprecated Since we are not using this class and this might lead to mis-use of this class, we will
- * removing this class in a future release.
+ *             removing this class in a future release.
  */
 public class SOAPUtil {
     private static final Log log = LogFactory.getLog(SOAPUtil.class);
@@ -53,13 +53,13 @@
                                       HttpServletRequest request,
                                       HttpServletResponse response) throws AxisFault {
         try {
-            response.setHeader("Content-Type","text/html");
+            response.setHeader("Content-Type", "text/html");
 
-            if(server(msgContext) != null){
-                response.setHeader("Server",server(msgContext));
+            if (server(msgContext) != null) {
+                response.setHeader("Server", server(msgContext));
             }
             String soapAction = request.getHeader(HTTPConstants.HEADER_SOAP_ACTION);
-            msgContext.setProperty(Constants.Configuration.CONTENT_TYPE,request.getContentType());
+            msgContext.setProperty(Constants.Configuration.CONTENT_TYPE, request.getContentType());
             HTTPTransportUtils.processHTTPPostRequest(msgContext,
                                                       request.getInputStream(),
                                                       response.getOutputStream(),
@@ -69,11 +69,12 @@
 
             Object contextWritten = null;
             if (msgContext.getOperationContext() != null) {
-                contextWritten = msgContext.getOperationContext().getProperty(Constants.RESPONSE_WRITTEN);
+                contextWritten =
+                        msgContext.getOperationContext().getProperty(Constants.RESPONSE_WRITTEN);
             }
 
             response.setContentType("text/xml; charset="
-                                    + msgContext.getProperty(Constants.Configuration.CHARACTER_SET_ENCODING));
+                    + msgContext.getProperty(Constants.Configuration.CHARACTER_SET_ENCODING));
 
             if ((contextWritten == null) || !Constants.VALUE_TRUE.equals(contextWritten)) {
                 Integer statusCode = (Integer) msgContext.getProperty(Constants.RESPONSE_CODE);
@@ -81,11 +82,12 @@
                     response.setStatus(statusCode.intValue());
                 } else {
                     response.setStatus(HttpServletResponse.SC_ACCEPTED);
-            }
+                }
             }
 
             boolean closeReader = true;
-            Parameter parameter = msgContext.getConfigurationContext().getAxisConfiguration().getParameter("axis2.close.reader");
+            Parameter parameter = msgContext.getConfigurationContext().getAxisConfiguration()
+                    .getParameter("axis2.close.reader");
             if (parameter != null) {
                 closeReader = JavaUtils.isTrueExplicitly(parameter.getValue());
             }
@@ -106,8 +108,9 @@
     }
 
     private String server(MessageContext messageContext) {
-        if (messageContext.getParameter(HTTPConstants.SERVER) != null){
-            OMElement userAgentElement = messageContext.getParameter(HTTPConstants.SERVER).getParameterElement();
+        if (messageContext.getParameter(HTTPConstants.SERVER) != null) {
+            OMElement userAgentElement =
+                    messageContext.getParameter(HTTPConstants.SERVER).getParameterElement();
             return userAgentElement.getText().trim();
 
         }

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/util/URIEncoderDecoder.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/util/URIEncoderDecoder.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/util/URIEncoderDecoder.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/util/URIEncoderDecoder.java Sun Mar  4 10:16:54 2007
@@ -16,9 +16,9 @@
 
 package org.apache.axis2.transport.http.util;
 
-import java.net.URISyntaxException;
-import java.io.UnsupportedEncodingException;
 import java.io.ByteArrayOutputStream;
+import java.io.UnsupportedEncodingException;
+import java.net.URISyntaxException;
 
 public class URIEncoderDecoder {
 
@@ -28,19 +28,16 @@
 
     /**
      * Validate a string by checking if it contains any characters other than:
-     *
+     * <p/>
      * 1. letters ('a'..'z', 'A'..'Z') 2. numbers ('0'..'9') 3. characters in
      * the legalset parameter 4. others (Unicode characters that are not in
      * US-ASCII set, and are not ISO Control or are not ISO Space characters)
-     * <p>
+     * <p/>
      * called from URI.Helper.parseURI() to validate each component
-     * <p>
-     *
-     * @param s
-     *            java.lang.String the string to be validated
-     * @param legal
-     *            java.lang.String the characters allowed in the String s
+     * <p/>
      *
+     * @param s     java.lang.String the string to be validated
+     * @param legal java.lang.String the characters allowed in the String s
      */
     static void validate(String s, String legal) throws URISyntaxException {
         for (int i = 0; i < s.length();) {
@@ -53,7 +50,8 @@
                     int d1 = Character.digit(s.charAt(i + 1), 16);
                     int d2 = Character.digit(s.charAt(i + 2), 16);
                     if (d1 == -1 || d2 == -1) {
-                        throw new URISyntaxException(s, "Invalid % sequence " + s.substring(i, i + 3)
+                        throw new URISyntaxException(s,
+                                                     "Invalid % sequence " + s.substring(i, i + 3)
                                 , i);
                     }
 
@@ -88,20 +86,18 @@
      * All characters except letters ('a'..'z', 'A'..'Z') and numbers ('0'..'9')
      * and legal characters are converted into their hexidecimal value prepended
      * by '%'.
-     * <p>
+     * <p/>
      * For example: '#' -> %23
-     * <p>
+     * <p/>
      * Other characters, which are Unicode chars that are not US-ASCII, and are
      * not ISO Control or are not ISO Space chars, are preserved.
-     * <p>
+     * <p/>
      * Called from URI.quoteComponent() (for multiple argument constructors)
-     * <p>
+     * <p/>
      *
-     * @param s
-     *            java.lang.String the string to be converted
-     * @param legal
-     *            java.lang.String the characters allowed to be preserved in the
-     *            string s
+     * @param s     java.lang.String the string to be converted
+     * @param legal java.lang.String the characters allowed to be preserved in the
+     *              string s
      * @return java.lang.String the converted string
      */
     public static String quoteIllegal(String s, String legal)
@@ -114,10 +110,10 @@
                     || (ch >= '0' && ch <= '9')
                     || legal.indexOf(ch) > -1
                     || (ch > 127 && !Character.isSpaceChar(ch) && !Character
-                            .isISOControl(ch))) {
+                    .isISOControl(ch))) {
                 buf.append(ch);
             } else {
-                byte[] bytes = new String(new char[] { ch }).getBytes(encoding);
+                byte[] bytes = new String(new char[]{ch}).getBytes(encoding);
                 for (int j = 0; j < bytes.length; j++) {
                     buf.append('%');
                     buf.append(digits.charAt((bytes[j] & 0xf0) >> 4));
@@ -132,14 +128,13 @@
      * Other characters, which are Unicode chars that are not US-ASCII, and are
      * not ISO Control or are not ISO Space chars are not preserved. They are
      * converted into their hexidecimal value prepended by '%'.
-     * <p>
+     * <p/>
      * For example: Euro currency symbol -> "%E2%82%AC".
-     * <p>
+     * <p/>
      * Called from URI.toASCIIString()
-     * <p>
+     * <p/>
      *
-     * @param s
-     *            java.lang.String the string to be converted
+     * @param s java.lang.String the string to be converted
      * @return java.lang.String the converted string
      */
     static String encodeOthers(String s) throws UnsupportedEncodingException {
@@ -149,7 +144,7 @@
             if (ch <= 127) {
                 buf.append(ch);
             } else {
-                byte[] bytes = new String(new char[] { ch }).getBytes(encoding);
+                byte[] bytes = new String(new char[]{ch}).getBytes(encoding);
                 for (int j = 0; j < bytes.length; j++) {
                     buf.append('%');
                     buf.append(digits.charAt((bytes[j] & 0xf0) >> 4));
@@ -164,22 +159,21 @@
      * Decodes the string argument which is assumed to be encoded in the
      * <code>x-www-form-urlencoded</code> MIME content type using the UTF-8
      * encoding scheme.
-     * <p>
+     * <p/>
      * '%' and two following hex digit characters are converted to the
      * equivalent byte value. All other characters are passed through
      * unmodified.
-     *
-     * <p>
+     * <p/>
+     * <p/>
      * e.g. "A%20B%20C %24%25" -> "A B C $%"
-     * <p>
+     * <p/>
      * Called from URI.getXYZ() methods
-     * <p>
+     * <p/>
      *
-     * @param s
-     *            java.lang.String The encoded string.
+     * @param s java.lang.String The encoded string.
      * @return java.lang.String The decoded version.
      */
-   public static String decode(String s) throws UnsupportedEncodingException {
+    public static String decode(String s) throws UnsupportedEncodingException {
 
         StringBuffer result = new StringBuffer();
         ByteArrayOutputStream out = new ByteArrayOutputStream();
@@ -194,8 +188,9 @@
                     int d1 = Character.digit(s.charAt(i + 1), 16);
                     int d2 = Character.digit(s.charAt(i + 2), 16);
                     if (d1 == -1 || d2 == -1) {
-                        throw new IllegalArgumentException("Invalid % sequence" +  s.substring(i, i + 3) + "at " +
-                                String.valueOf(i));
+                        throw new IllegalArgumentException(
+                                "Invalid % sequence" + s.substring(i, i + 3) + "at " +
+                                        String.valueOf(i));
                     }
                     out.write((byte) ((d1 << 4) + d2));
                     i += 3;

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/util/URLTemplatingUtil.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/util/URLTemplatingUtil.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/util/URLTemplatingUtil.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/http/util/URLTemplatingUtil.java Sun Mar  4 10:16:54 2007
@@ -28,7 +28,6 @@
 import java.io.UnsupportedEncodingException;
 import java.net.MalformedURLException;
 import java.net.URL;
-import java.net.URLEncoder;
 import java.util.Iterator;
 
 
@@ -86,7 +85,7 @@
      * Appends Query parameters to the URL
      *
      * @param messageContext - The MessageContext of the request
-     * @param url          - Original url string
+     * @param url            - Original url string
      * @return String containing the appended query parameters
      */
     private static String appendQueryParameters(MessageContext messageContext, String url) {
@@ -118,12 +117,11 @@
 
             int index = url.indexOf("?");
             if (index == -1) {
-                url = url + "?" + params.substring(0,params.length()-1);
-            }
-            else if (index == url.length() - 1) {
-                url = url + params.substring(0,params.length()-1);
+                url = url + "?" + params.substring(0, params.length() - 1);
+            } else if (index == url.length() - 1) {
+                url = url + params.substring(0, params.length() - 1);
             } else {
-                url = url + queryParameterSeparator + params.substring(0,params.length()-1);
+                url = url + queryParameterSeparator + params.substring(0, params.length() - 1);
             }
 
         }

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/jms/JMSConnectionFactory.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/jms/JMSConnectionFactory.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/jms/JMSConnectionFactory.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/jms/JMSConnectionFactory.java Sun Mar  4 10:16:54 2007
@@ -53,26 +53,26 @@
  * defined in the Axis2 configuration.
  * <p/>
  * e.g.
- *   <transportReceiver name="jms" class="org.apache.axis2.transport.jms.JMSListener">
- *       <parameter name="myTopicConnectionFactory" locked="false">
- *           <parameter name="java.naming.factory.initial" locked="false">org.apache.activemq.jndi.ActiveMQInitialContextFactory</parameter>
- *           <parameter name="java.naming.provider.url" locked="false">tcp://localhost:61616</parameter>
- *           <parameter name="transport.jms.ConnectionFactoryJNDIName" locked="false">TopicConnectionFactory</parameter>
- *           <parameter name="transport.jms.Destination" locked="false">myTopicOne, myTopicTwo</parameter>
- *       </parameter>
- *       <parameter name="myQueueConnectionFactory" locked="false">
- *           <parameter name="java.naming.factory.initial" locked="false">org.apache.activemq.jndi.ActiveMQInitialContextFactory</parameter>
- *           <parameter name="java.naming.provider.url" locked="false">tcp://localhost:61616</parameter>
- *           <parameter name="transport.jms.ConnectionFactoryJNDIName" locked="false">QueueConnectionFactory</parameter>
- *           <parameter name="transport.jms.Destination" locked="false">myQueueOne, myQueueTwo</parameter>
- *       </parameter>
- *       <parameter name="default" locked="false">
- *           <parameter name="java.naming.factory.initial" locked="false">org.apache.activemq.jndi.ActiveMQInitialContextFactory</parameter>
- *           <parameter name="java.naming.provider.url" locked="false">tcp://localhost:61616</parameter>
- *           <parameter name="transport.jms.ConnectionFactoryJNDIName" locked="false">ConnectionFactory</parameter>
- *           <parameter name="transport.jms.Destination" locked="false">myDestinationOne, myDestinationTwo</parameter>
- *       </parameter>
- *   </transportReceiver>
+ * <transportReceiver name="jms" class="org.apache.axis2.transport.jms.JMSListener">
+ * <parameter name="myTopicConnectionFactory" locked="false">
+ * <parameter name="java.naming.factory.initial" locked="false">org.apache.activemq.jndi.ActiveMQInitialContextFactory</parameter>
+ * <parameter name="java.naming.provider.url" locked="false">tcp://localhost:61616</parameter>
+ * <parameter name="transport.jms.ConnectionFactoryJNDIName" locked="false">TopicConnectionFactory</parameter>
+ * <parameter name="transport.jms.Destination" locked="false">myTopicOne, myTopicTwo</parameter>
+ * </parameter>
+ * <parameter name="myQueueConnectionFactory" locked="false">
+ * <parameter name="java.naming.factory.initial" locked="false">org.apache.activemq.jndi.ActiveMQInitialContextFactory</parameter>
+ * <parameter name="java.naming.provider.url" locked="false">tcp://localhost:61616</parameter>
+ * <parameter name="transport.jms.ConnectionFactoryJNDIName" locked="false">QueueConnectionFactory</parameter>
+ * <parameter name="transport.jms.Destination" locked="false">myQueueOne, myQueueTwo</parameter>
+ * </parameter>
+ * <parameter name="default" locked="false">
+ * <parameter name="java.naming.factory.initial" locked="false">org.apache.activemq.jndi.ActiveMQInitialContextFactory</parameter>
+ * <parameter name="java.naming.provider.url" locked="false">tcp://localhost:61616</parameter>
+ * <parameter name="transport.jms.ConnectionFactoryJNDIName" locked="false">ConnectionFactory</parameter>
+ * <parameter name="transport.jms.Destination" locked="false">myDestinationOne, myDestinationTwo</parameter>
+ * </parameter>
+ * </transportReceiver>
  */
 public class JMSConnectionFactory {
 
@@ -118,7 +118,7 @@
     /**
      * Create a JMSConnectionFactory for the given Axis2 name and JNDI name
      *
-     * @param name the local Axis2 name of the connection factory
+     * @param name     the local Axis2 name of the connection factory
      * @param jndiName the JNDI name of the actual connection factory used
      */
     JMSConnectionFactory(String name, String jndiName) {
@@ -173,7 +173,7 @@
      * Add a listen destination on this connection factory on behalf of the given service
      *
      * @param destinationJndi destination JNDI name
-     * @param serviceName the service to which it belongs
+     * @param serviceName     the service to which it belongs
      */
     public void addDestination(String destinationJndi, String serviceName) {
         destinations.put(destinationJndi, serviceName);
@@ -261,13 +261,13 @@
 
         if (conFactory == null || context == null) {
             handleException(
-                "Connection factory must be 'connected' before listening");
+                    "Connection factory must be 'connected' before listening");
         } else {
             try {
                 connection = conFactory.createConnection();
             } catch (JMSException e) {
                 handleException("Error creating a JMS connection using the " +
-                    "factory : " + jndiName, e);
+                        "factory : " + jndiName, e);
             }
         }
 
@@ -299,16 +299,16 @@
 
         } catch (NameNotFoundException e) {
             log.warn("Cannot find destination : " + destinationJndi +
-                " Creating a Queue with this name");
+                    " Creating a Queue with this name");
             destination = session.createQueue(destinationJndi);
 
         } catch (NamingException e) {
             log.warn("Error looking up destination : " + destinationJndi, e);
             // mark service as faulty
             JMSUtils.markServiceAsFaulty(
-                (String) destinations.get(destinationJndi),
-                "Error looking up JMS destination : " + destinationJndi,
-                this.msgRcvr.getAxisConf().getAxisConfiguration());
+                    (String) destinations.get(destinationJndi),
+                    "Error looking up JMS destination : " + destinationJndi,
+                    this.msgRcvr.getAxisConf().getAxisConfiguration());
         }
 
         MessageConsumer consumer = session.createConsumer(destination);



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