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

svn commit: r514453 [15/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/jms/JMSConstants.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/jms/JMSConstants.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/jms/JMSConstants.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/jms/JMSConstants.java Sun Mar  4 10:16:54 2007
@@ -79,7 +79,8 @@
     /**
      * The name of the element which wraps non SOAP/XML content into a SOAP envelope
      */
-    public static final QName DEFAULT_WRAPPER = new QName(Constants.AXIS2_NAMESPACE_URI, "jmsMessage");
+    public static final QName DEFAULT_WRAPPER =
+            new QName(Constants.AXIS2_NAMESPACE_URI, "jmsMessage");
 
     /**
      * The local (Axis2) JMS connection factory name of the default connection

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/jms/JMSListener.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/jms/JMSListener.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/jms/JMSListener.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/jms/JMSListener.java Sun Mar  4 10:16:54 2007
@@ -337,7 +337,8 @@
         if (serviceName.indexOf('/') != -1) {
             serviceName = serviceName.substring(0, serviceName.indexOf('/'));
         }
-        return new EndpointReference[]{new EndpointReference((String) serviceNameToEprMap.get(serviceName))};
+        return new EndpointReference[]{
+                new EndpointReference((String) serviceNameToEprMap.get(serviceName))};
     }
 
     /**

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/jms/JMSMessageReceiver.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/jms/JMSMessageReceiver.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/jms/JMSMessageReceiver.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/jms/JMSMessageReceiver.java Sun Mar  4 10:16:54 2007
@@ -62,12 +62,12 @@
     /**
      * Create a new JMSMessage receiver
      *
-     * @param jmsConFac the JMS connection factory associated with
+     * @param jmsConFac  the JMS connection factory associated with
      * @param workerPool the worker thead pool to be used
-     * @param axisConf the Axis2 configuration
+     * @param axisConf   the Axis2 configuration
      */
     JMSMessageReceiver(JMSConnectionFactory jmsConFac,
-        Executor workerPool, ConfigurationContext axisConf) {
+                       Executor workerPool, ConfigurationContext axisConf) {
         this.jmsConFac = jmsConFac;
         this.workerPool = workerPool;
         this.axisConf = axisConf;
@@ -100,7 +100,7 @@
         // directly create a new worker and delegate processing
         try {
             log.debug("Received JMS message to destination : " +
-                message.getJMSDestination());
+                    message.getJMSDestination());
         } catch (JMSException e) {
             e.printStackTrace();
         }
@@ -135,12 +135,12 @@
             // hack to get around the crazy Active MQ dynamic queue and topic issues
             if (serviceName == null) {
                 String provider = (String) jmsConFac.getProperties().get(
-                    Context.INITIAL_CONTEXT_FACTORY);
+                        Context.INITIAL_CONTEXT_FACTORY);
                 if (provider.indexOf("activemq") != -1) {
                     serviceName = jmsConFac.getServiceNameForDestination(
-                        ((dest instanceof Queue ?
-                            JMSConstants.ACTIVEMQ_DYNAMIC_QUEUE :
-                            JMSConstants.ACTIVEMQ_DYNAMIC_TOPIC) + destinationName));
+                            ((dest instanceof Queue ?
+                                    JMSConstants.ACTIVEMQ_DYNAMIC_QUEUE :
+                                    JMSConstants.ACTIVEMQ_DYNAMIC_TOPIC) + destinationName));
                 }
             }
 
@@ -148,19 +148,20 @@
             if (serviceName != null) {
                 // set to bypass dispatching and handover directly to this service
                 msgContext.setAxisService(
-                    axisConf.getAxisConfiguration().getService(serviceName));
+                        axisConf.getAxisConfiguration().getService(serviceName));
             }
 
             msgContext.setIncomingTransportName(Constants.TRANSPORT_JMS);
             msgContext.setTransportIn(
-                axisConf.getAxisConfiguration().getTransportIn(JMSConstants.JMS_QNAME));
+                    axisConf.getAxisConfiguration().getTransportIn(JMSConstants.JMS_QNAME));
 
             msgContext.setTransportOut(
-                axisConf.getAxisConfiguration().getTransportOut(JMSConstants.JMS_QNAME));
+                    axisConf.getAxisConfiguration().getTransportOut(JMSConstants.JMS_QNAME));
             // the reply is assumed to be on the JMSReplyTo destination, using
             // the same incoming connection factory
             msgContext.setProperty(Constants.OUT_TRANSPORT_INFO,
-                 new JMSOutTransportInfo(jmsConFac.getConFactory(), message.getJMSReplyTo()));
+                                   new JMSOutTransportInfo(jmsConFac.getConFactory(),
+                                                           message.getJMSReplyTo()));
 
             msgContext.setServerSide(true);
             msgContext.setServiceGroupContextId(UUIDGenerator.getUUID());
@@ -171,7 +172,7 @@
             }
 
             msgContext.setEnvelope(
-                JMSUtils.getSOAPEnvelope(message, msgContext, in));
+                    JMSUtils.getSOAPEnvelope(message, msgContext, in));
 
             return msgContext;
 
@@ -215,7 +216,7 @@
                 }
             } catch (AxisFault af) {
                 log.error("JMS Worker [" + Thread.currentThread().getName() +
-                    "] Encountered an Axis Fault : " + af.getMessage(), af);
+                        "] Encountered an Axis Fault : " + af.getMessage(), af);
             }
         }
     }

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/jms/JMSOutTransportInfo.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/jms/JMSOutTransportInfo.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/jms/JMSOutTransportInfo.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/jms/JMSOutTransportInfo.java Sun Mar  4 10:16:54 2007
@@ -43,7 +43,7 @@
      * Creates an instance using the given connection factory and destination
      *
      * @param connectionFactory the connection factory
-     * @param dest the destination
+     * @param dest              the destination
      */
     JMSOutTransportInfo(ConnectionFactory connectionFactory, Destination dest) {
         this.connectionFactory = connectionFactory;
@@ -58,7 +58,7 @@
     JMSOutTransportInfo(String url) {
         if (!url.startsWith(JMSConstants.JMS_PREFIX)) {
             handleException("Invalid JMS URL : " + url +
-                " Must begin with the prefix " + JMSConstants.JMS_PREFIX);
+                    " Must begin with the prefix " + JMSConstants.JMS_PREFIX);
         } else {
             Context context = null;
             Hashtable props = JMSUtils.getProperties(url);
@@ -77,7 +77,7 @@
      * Get the referenced ConnectionFactory using the properties from the context
      *
      * @param context the context to use for lookup
-     * @param props the properties which contains the JNDI name of the factory
+     * @param props   the properties which contains the JNDI name of the factory
      * @return the connection factory
      */
     private ConnectionFactory getConnectionFactory(Context context, Hashtable props) {
@@ -88,7 +88,7 @@
                 return (ConnectionFactory) context.lookup(conFacJndiName);
             } else {
                 throw new NamingException(
-                    "JMS Connection Factory JNDI name cannot be determined from url");
+                        "JMS Connection Factory JNDI name cannot be determined from url");
             }
         } catch (NamingException e) {
             handleException("Cannot get JMS Connection factory with props : " + props, e);
@@ -100,7 +100,7 @@
      * Get the JMS destination specified by the given URL from the context
      *
      * @param context the Context to lookup
-     * @param url URL
+     * @param url     URL
      * @return the JMS destination, or null if it does not exist
      */
     private Destination getDestination(Context context, String url) {
@@ -110,11 +110,11 @@
 
         } catch (NameNotFoundException e) {
             log.warn("Cannot get or lookup JMS destination : " + destinationName +
-                " from url : " + url + " : " + e.getMessage());
+                    " from url : " + url + " : " + e.getMessage());
 
         } catch (NamingException e) {
             handleException("Cannot get JMS destination : " + destinationName +
-                " from url : " + url, e);
+                    " from url : " + url, e);
         }
         return null;
     }

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/jms/JMSSender.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/jms/JMSSender.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/jms/JMSSender.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/jms/JMSSender.java Sun Mar  4 10:16:54 2007
@@ -63,24 +63,24 @@
 
         // is there a transport url? which may be different from the WS-A To..
         targetAddress = (String) msgContext.getProperty(
-            Constants.Configuration.TRANSPORT_URL);
+                Constants.Configuration.TRANSPORT_URL);
 
         if (targetAddress != null) {
-            transportInfo = new JMSOutTransportInfo(targetAddress);            
+            transportInfo = new JMSOutTransportInfo(targetAddress);
         } else if (targetAddress == null && msgContext.getTo() != null &&
-            !msgContext.getTo().hasAnonymousAddress()) {
+                !msgContext.getTo().hasAnonymousAddress()) {
             targetAddress = msgContext.getTo().getAddress();
-            
+
             if (!msgContext.getTo().hasNoneAddress()) {
                 transportInfo = new JMSOutTransportInfo(targetAddress);
             } else {
                 //Don't send the message.
-              return InvocationResponse.CONTINUE;        
+                return InvocationResponse.CONTINUE;
             }
         } else if (msgContext.isServerSide()) {
             // get the jms ReplyTo
             transportInfo = (JMSOutTransportInfo)
-                msgContext.getProperty(Constants.OUT_TRANSPORT_INFO);                
+                    msgContext.getProperty(Constants.OUT_TRANSPORT_INFO);
         }
 
         // should we wait and listen for a response?
@@ -130,14 +130,14 @@
             }
 
             try {
-                log.debug("[" + (msgContext.isServerSide()?"Server" : "Client") +
-                    "]Sending message to destination : " + dest);
+                log.debug("[" + (msgContext.isServerSide() ? "Server" : "Client") +
+                        "]Sending message to destination : " + dest);
                 producer.send(message);
                 producer.close();
 
             } catch (JMSException e) {
                 handleException("Error sending JMS message to destination : " +
-                    dest.toString(), e);
+                        dest.toString(), e);
             }
 
             if (waitForResponse) {
@@ -152,21 +152,21 @@
                     }
 
                     log.debug("Waiting for a maximum of " + timeout +
-                        "ms for a response message to destination : " + replyDest);
+                            "ms for a response message to destination : " + replyDest);
                     con.start();
                     Message reply = consumer.receive(timeout);
 
                     if (reply != null) {
                         msgContext.setProperty(MessageContext.TRANSPORT_IN,
-                            JMSUtils.getInputStream(reply));
+                                               JMSUtils.getInputStream(reply));
                     } else {
                         log.warn("Did not receive a JMS response within " +
-                            timeout + " ms to destination : " + dest);
+                                timeout + " ms to destination : " + dest);
                     }
 
                 } catch (JMSException e) {
                     handleException("Error reading response from temporary " +
-                        "queue : " + replyDest, e);
+                            "queue : " + replyDest, e);
                 }
             }
         } catch (JMSException e) {
@@ -180,7 +180,7 @@
                 } // ignore
             }
         }
-        return InvocationResponse.CONTINUE;        
+        return InvocationResponse.CONTINUE;
     }
 
     public void cleanup(MessageContext msgContext) throws AxisFault {
@@ -188,7 +188,7 @@
     }
 
     public void init(ConfigurationContext confContext,
-        TransportOutDescription transportOut) throws AxisFault {
+                     TransportOutDescription transportOut) throws AxisFault {
         // do nothing
     }
 
@@ -201,12 +201,12 @@
      * session
      *
      * @param msgContext the MessageContext
-     * @param session the JMS session
+     * @param session    the JMS session
      * @return a JMS message from the context and session
      * @throws JMSException on exception
      */
     private Message createJMSMessage(MessageContext msgContext, Session session)
-        throws JMSException {
+            throws JMSException {
 
         Message message = null;
         String msgType = getProperty(msgContext, JMSConstants.JMS_MESSAGE_TYPE);
@@ -223,7 +223,7 @@
             ByteArrayOutputStream baos = new ByteArrayOutputStream();
             OMOutputFormat format = new OMOutputFormat();
             format.setCharSetEncoding(
-                 getProperty(msgContext, Constants.Configuration.CHARACTER_SET_ENCODING));
+                    getProperty(msgContext, Constants.Configuration.CHARACTER_SET_ENCODING));
             format.setDoOptimize(msgContext.isDoingMTOM());
             try {
                 msgElement.serializeAndConsume(baos, format);

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/jms/JMSUtils.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/jms/JMSUtils.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/jms/JMSUtils.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/jms/JMSUtils.java Sun Mar  4 10:16:54 2007
@@ -15,20 +15,6 @@
 */
 package org.apache.axis2.transport.jms;
 
-import java.io.ByteArrayInputStream;
-import java.io.ByteArrayOutputStream;
-import java.io.InputStream;
-import java.io.UnsupportedEncodingException;
-import java.util.Hashtable;
-import java.util.List;
-import java.util.StringTokenizer;
-
-import javax.jms.BytesMessage;
-import javax.jms.JMSException;
-import javax.jms.Message;
-import javax.jms.TextMessage;
-import javax.xml.stream.XMLStreamException;
-
 import org.apache.axiom.om.OMOutputFormat;
 import org.apache.axiom.om.impl.builder.StAXBuilder;
 import org.apache.axiom.soap.SOAP11Constants;
@@ -47,6 +33,19 @@
 import org.apache.commons.logging.Log;
 import org.apache.commons.logging.LogFactory;
 
+import javax.jms.BytesMessage;
+import javax.jms.JMSException;
+import javax.jms.Message;
+import javax.jms.TextMessage;
+import javax.xml.stream.XMLStreamException;
+import java.io.ByteArrayInputStream;
+import java.io.ByteArrayOutputStream;
+import java.io.InputStream;
+import java.io.UnsupportedEncodingException;
+import java.util.Hashtable;
+import java.util.List;
+import java.util.StringTokenizer;
+
 public class JMSUtils {
 
     private static final Log log = LogFactory.getLog(JMSUtils.class);
@@ -64,7 +63,7 @@
 
         } else {
             List transports = service.getExposedTransports();
-            for (int i=0; i<transports.size(); i++) {
+            for (int i = 0; i < transports.size(); i++) {
                 if (Constants.TRANSPORT_JMS.equals(transports.get(i))) {
                     return true;
                 }
@@ -103,12 +102,12 @@
         Hashtable h = new Hashtable();
         int propPos = url.indexOf("?");
         if (propPos != -1) {
-            StringTokenizer st = new StringTokenizer(url.substring(propPos+1), "&");
+            StringTokenizer st = new StringTokenizer(url.substring(propPos + 1), "&");
             while (st.hasMoreTokens()) {
                 String token = st.nextToken();
                 int sep = token.indexOf("=");
                 if (sep != -1) {
-                    h.put(token.substring(0, sep), token.substring(sep+1));
+                    h.put(token.substring(0, sep), token.substring(sep + 1));
                 } else {
                     continue; // ignore, what else can we do?
                 }
@@ -121,11 +120,11 @@
      * Marks the given service as faulty with the given comment
      *
      * @param serviceName service name
-     * @param msg comment for being faulty
-     * @param axisCfg configuration context
+     * @param msg         comment for being faulty
+     * @param axisCfg     configuration context
      */
     public static void markServiceAsFaulty(String serviceName, String msg,
-                                           AxisConfiguration axisCfg ) {
+                                           AxisConfiguration axisCfg) {
         if (serviceName != null) {
             try {
                 AxisService service = axisCfg.getService(serviceName);
@@ -133,7 +132,7 @@
 
             } catch (AxisFault axisFault) {
                 log.warn("Error marking service : " + serviceName +
-                         " as faulty due to : " + msg, axisFault);
+                        " as faulty due to : " + msg, axisFault);
             }
         }
     }
@@ -164,17 +163,17 @@
                 String contentType = message.getStringProperty(JMSConstants.CONTENT_TYPE);
                 if (contentType != null) {
                     return
-                        new ByteArrayInputStream(
-                            txtMsg.getText().getBytes(
-                            BuilderUtil.getCharSetEncoding(contentType)));
+                            new ByteArrayInputStream(
+                                    txtMsg.getText().getBytes(
+                                            BuilderUtil.getCharSetEncoding(contentType)));
                 } else {
                     return
-                        new ByteArrayInputStream(txtMsg.getText().getBytes());
+                            new ByteArrayInputStream(txtMsg.getText().getBytes());
                 }
 
             } else {
                 handleException("Unsupported JMS message type : " +
-                                message.getClass().getName());
+                        message.getClass().getName());
             }
 
 
@@ -189,7 +188,7 @@
     /**
      * Get a String property from the JMS message
      *
-     * @param message JMS message
+     * @param message  JMS message
      * @param property property name
      * @return property value
      */
@@ -211,7 +210,7 @@
         OMOutputFormat format = new OMOutputFormat();
         String soapActionString = getSOAPAction(msgCtx);
         String charSetEnc = (String) msgCtx.getProperty(
-            Constants.Configuration.CHARACTER_SET_ENCODING);
+                Constants.Configuration.CHARACTER_SET_ENCODING);
 
         if (charSetEnc != null) {
             format.setCharSetEncoding(charSetEnc);
@@ -219,7 +218,7 @@
             OperationContext opctx = msgCtx.getOperationContext();
             if (opctx != null) {
                 charSetEnc = (String) opctx.getProperty(
-                    Constants.Configuration.CHARACTER_SET_ENCODING);
+                        Constants.Configuration.CHARACTER_SET_ENCODING);
             }
         }
 
@@ -240,7 +239,7 @@
 
         // action header is not mandated in SOAP 1.2. So putting it, if available
         if (!msgCtx.isSOAP11() && soapActionString != null &&
-            !"".equals(soapActionString.trim())) {
+                !"".equals(soapActionString.trim())) {
             contentType = contentType + ";action=\"" + soapActionString + "\";";
         }
 
@@ -261,8 +260,8 @@
         }
 
         Object disableSoapAction =
-            msgCtx.getOptions().getProperty(Constants.Configuration.DISABLE_SOAP_ACTION);
-        
+                msgCtx.getOptions().getProperty(Constants.Configuration.DISABLE_SOAP_ACTION);
+
         if (soapActionString == null || JavaUtils.isTrueExplicitly(disableSoapAction)) {
             soapActionString = "";
         }
@@ -291,16 +290,16 @@
      * Return a SOAPEnvelope created from the given JMS Message and Axis
      * MessageContext, and the InputStream into the message
      *
-     * @param message the JMS Message
+     * @param message    the JMS Message
      * @param msgContext the Axis MessageContext
-     * @param in the InputStream into the message
+     * @param in         the InputStream into the message
      * @return SOAPEnvelope for the message
      * @throws javax.xml.stream.XMLStreamException
      *
      */
     public static SOAPEnvelope getSOAPEnvelope(
-        Message message, MessageContext msgContext, InputStream in)
-        throws XMLStreamException {
+            Message message, MessageContext msgContext, InputStream in)
+            throws XMLStreamException {
 
         SOAPEnvelope envelope = null;
         StAXBuilder builder;
@@ -323,26 +322,26 @@
 
         String charEncOfMessage = builder.getCharsetEncoding();
         String charEncOfTransport = ((String) msgContext.getProperty(
-            Constants.Configuration.CHARACTER_SET_ENCODING));
+                Constants.Configuration.CHARACTER_SET_ENCODING));
 
         if (charEncOfMessage != null &&
-            !(charEncOfMessage.trim().length() == 0) &&
-            !charEncOfMessage.equalsIgnoreCase(charEncOfTransport)) {
+                !(charEncOfMessage.trim().length() == 0) &&
+                !charEncOfMessage.equalsIgnoreCase(charEncOfTransport)) {
 
             String faultCode;
 
             if (envelope.getNamespace() != null &&
-                SOAP12Constants.SOAP_ENVELOPE_NAMESPACE_URI.
-                    equals(envelope.getNamespace().getNamespaceURI())) {
+                    SOAP12Constants.SOAP_ENVELOPE_NAMESPACE_URI.
+                            equals(envelope.getNamespace().getNamespaceURI())) {
                 faultCode = SOAP12Constants.FAULT_CODE_SENDER;
             } else {
                 faultCode = SOAP11Constants.FAULT_CODE_SENDER;
             }
 
             handleException(
-                "Character Set Encoding from transport information do not " +
-                "match with character set encoding in the received " +
-                "SOAP message");
+                    "Character Set Encoding from transport information do not " +
+                            "match with character set encoding in the received " +
+                            "SOAP message");
         }
         return envelope;
     }

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/local/LocalResponder.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/local/LocalResponder.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/local/LocalResponder.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/local/LocalResponder.java Sun Mar  4 10:16:54 2007
@@ -90,7 +90,7 @@
         // not available
         if (msgContext.getOperationContext() != null) {
             msgContext.getOperationContext().setProperty(Constants.RESPONSE_WRITTEN,
-                    Constants.VALUE_TRUE);
+                                                         Constants.VALUE_TRUE);
         }
         return InvocationResponse.CONTINUE;
     }

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/local/LocalTransportSender.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/local/LocalTransportSender.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/local/LocalTransportSender.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/local/LocalTransportSender.java Sun Mar  4 10:16:54 2007
@@ -35,7 +35,7 @@
 import java.io.OutputStream;
 
 public class LocalTransportSender extends AbstractHandler implements TransportSender {
-    
+
     private ByteArrayOutputStream out;
     private ByteArrayOutputStream response;
 
@@ -94,7 +94,7 @@
         // not available
         if (msgContext.getOperationContext() != null) {
             msgContext.getOperationContext().setProperty(Constants.RESPONSE_WRITTEN,
-                    Constants.VALUE_TRUE);
+                                                         Constants.VALUE_TRUE);
         }
         return InvocationResponse.CONTINUE;
     }

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/mail/Constants.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/mail/Constants.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/mail/Constants.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/mail/Constants.java Sun Mar  4 10:16:54 2007
@@ -72,7 +72,7 @@
     public final static String LIST = "LIST";
     public final static String DELE = "DELE";
 
-	public static final String MAIL_SMTP = "_MAIL_SMTP_";
+    public static final String MAIL_SMTP = "_MAIL_SMTP_";
 
-	public static final String MAIL_POP3 = "_MAIL_POP3_";
+    public static final String MAIL_POP3 = "_MAIL_POP3_";
 }

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/mail/EMailSender.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/mail/EMailSender.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/mail/EMailSender.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/mail/EMailSender.java Sun Mar  4 10:16:54 2007
@@ -139,7 +139,7 @@
                 .addHeader("Content-Description", "\"" + mailToInfo.getContentDescription() + "\"");
 
         String contentType = format.getContentType() != null ? format.getContentType() :
-                             Constants.DEFAULT_CONTENT_TYPE;
+                Constants.DEFAULT_CONTENT_TYPE;
         if (contentType.indexOf(SOAP11Constants.SOAP_11_CONTENT_TYPE) > -1) {
             if (messageContext.getSoapAction() != null) {
                 messageBodyPart.setHeader(Constants.HEADER_SOAP_ACTION,
@@ -151,7 +151,8 @@
             if (messageContext.getSoapAction() != null) {
                 messageBodyPart.setHeader("Content-Type",
                                           contentType + "; charset=" + format.getCharSetEncoding() +
-                                          " ; action=\"" + messageContext.getSoapAction() + "\"");
+                                                  " ; action=\"" + messageContext.getSoapAction() +
+                                                  "\"");
             }
         } else {
             messageBodyPart.setHeader("Content-Type",

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/mail/EmailReceiver.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/mail/EmailReceiver.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/mail/EmailReceiver.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/mail/EmailReceiver.java Sun Mar  4 10:16:54 2007
@@ -51,7 +51,7 @@
     public void connect() throws AxisFault {
         try {
 
-            Session session = Session.getInstance(pop3Properties,null);
+            Session session = Session.getInstance(pop3Properties, null);
             store = session.getStore(urlName);
 
             store.connect();

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/mail/MailTransportSender.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/mail/MailTransportSender.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/mail/MailTransportSender.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/mail/MailTransportSender.java Sun Mar  4 10:16:54 2007
@@ -17,9 +17,7 @@
 
 package org.apache.axis2.transport.mail;
 
-import org.apache.axiom.om.OMElement;
 import org.apache.axiom.om.OMOutputFormat;
-import org.apache.axiom.soap.SOAPEnvelope;
 import org.apache.axis2.AxisFault;
 import org.apache.axis2.addressing.EndpointReference;
 import org.apache.axis2.context.ConfigurationContext;
@@ -253,7 +251,7 @@
         try {
             OMOutputFormat format = new OMOutputFormat();
             MessageFormatter messageFormatter = TransportUtils
-                .getMessageFormatter(msgContext);
+                    .getMessageFormatter(msgContext);
             format.setDoOptimize(msgContext.isDoingMTOM());
             //Set to null so that the code will not fail on 7bit.
             format.setCharSetEncoding(null);

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/mail/MailWorker.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/mail/MailWorker.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/mail/MailWorker.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/mail/MailWorker.java Sun Mar  4 10:16:54 2007
@@ -58,7 +58,7 @@
                 try {
                     if (msgContext != null) {
                         MessageContext faultContext =
-                            MessageContextBuilder.createFaultMessageContext(msgContext, e);
+                                MessageContextBuilder.createFaultMessageContext(msgContext, e);
                         engine.sendFault(faultContext);
                     }
                 } catch (Exception e1) {

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/mail/MimeBase64BodyPart.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/mail/MimeBase64BodyPart.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/mail/MimeBase64BodyPart.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/mail/MimeBase64BodyPart.java Sun Mar  4 10:16:54 2007
@@ -27,6 +27,6 @@
 
     protected void updateHeaders() throws MessagingException {
         super.updateHeaders();
-        setHeader("Content-Transfer-Encoding","base64");
+        setHeader("Content-Transfer-Encoding", "base64");
     }
 }

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/mail/SimpleMailListener.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/mail/SimpleMailListener.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/mail/SimpleMailListener.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/mail/SimpleMailListener.java Sun Mar  4 10:16:54 2007
@@ -17,25 +17,10 @@
 
 package org.apache.axis2.transport.mail;
 
-import java.io.File;
-import java.io.IOException;
-import java.io.InputStream;
-import java.util.ArrayList;
-import java.util.Iterator;
-import java.util.Properties;
-
-import javax.mail.Flags;
-import javax.mail.Message;
-import javax.mail.MessagingException;
-import javax.mail.Multipart;
-import javax.mail.Part;
-import javax.mail.URLName;
-import javax.mail.internet.MimeMessage;
-import javax.xml.namespace.QName;
-import javax.xml.stream.XMLStreamException;
-
-import org.apache.axiom.om.impl.builder.StAXBuilder;
-import org.apache.axiom.soap.SOAP11Constants;
+import edu.emory.mathcs.backport.java.util.concurrent.ExecutorService;
+import edu.emory.mathcs.backport.java.util.concurrent.LinkedBlockingQueue;
+import edu.emory.mathcs.backport.java.util.concurrent.ThreadPoolExecutor;
+import edu.emory.mathcs.backport.java.util.concurrent.TimeUnit;
 import org.apache.axiom.soap.SOAP12Constants;
 import org.apache.axiom.soap.SOAPEnvelope;
 import org.apache.axis2.AxisFault;
@@ -58,10 +43,21 @@
 import org.apache.commons.logging.Log;
 import org.apache.commons.logging.LogFactory;
 
-import edu.emory.mathcs.backport.java.util.concurrent.ExecutorService;
-import edu.emory.mathcs.backport.java.util.concurrent.LinkedBlockingQueue;
-import edu.emory.mathcs.backport.java.util.concurrent.ThreadPoolExecutor;
-import edu.emory.mathcs.backport.java.util.concurrent.TimeUnit;
+import javax.mail.Flags;
+import javax.mail.Message;
+import javax.mail.MessagingException;
+import javax.mail.Multipart;
+import javax.mail.Part;
+import javax.mail.URLName;
+import javax.mail.internet.MimeMessage;
+import javax.xml.namespace.QName;
+import javax.xml.stream.XMLStreamException;
+import java.io.File;
+import java.io.IOException;
+import java.io.InputStream;
+import java.util.ArrayList;
+import java.util.Iterator;
+import java.util.Properties;
 
 /**
  * This is the implementation for Mail Listener in Axis2. It has the full capability
@@ -153,7 +149,7 @@
 
         }
         if (password.length() == 0 || user.length() == 0 || host.length() == 0 ||
-            protocol.length() == 0) {
+                protocol.length() == 0) {
             throw new AxisFault(
                     "One or more of Password, User, Host and Protocol are null or empty");
         }
@@ -198,7 +194,7 @@
             if (transportIn != null) {
                 sas.init(configurationContext, transportIn);
                 log.info("Starting the SimpleMailListener with repository "
-                         + new File(args[0]).getAbsolutePath());
+                        + new File(args[0]).getAbsolutePath());
                 sas.start();
             } else {
                 log.info(
@@ -326,11 +322,14 @@
                             msgContext.setTo(new EndpointReference(contentDescription));
                         }
 
-                        if (part.getContentType().indexOf(SOAP12Constants.SOAP_12_CONTENT_TYPE)> -1) {
-                            TransportUtils.processContentTypeForAction(part.getContentType(),msgContext);
+                        if (part.getContentType().indexOf(SOAP12Constants.SOAP_12_CONTENT_TYPE) >
+                                -1) {
+                            TransportUtils
+                                    .processContentTypeForAction(part.getContentType(), msgContext);
                         }
                         InputStream inputStream = part.getInputStream();
-                        SOAPEnvelope envelope  = TransportUtils.createSOAPMessage(msgContext,inputStream, part.getContentType());
+                        SOAPEnvelope envelope = TransportUtils
+                                .createSOAPMessage(msgContext, inputStream, part.getContentType());
                         msgContext.setEnvelope(envelope);
                     }
                 }
@@ -415,12 +414,12 @@
 
     public EndpointReference[] getEPRsForService(String serviceName, String ip) throws AxisFault {
         return new EndpointReference[]{new EndpointReference(Constants.TRANSPORT_MAIL + ":" +
-                                                             replyTo + "?" + configurationContext
+                replyTo + "?" + configurationContext
                 .getServiceContextPath() + "/" + serviceName)};
     }
 
 
     public SessionContext getSessionContext(MessageContext messageContext) {
-        return null;  
+        return null;
     }
 }

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/mail/server/MailAddress.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/mail/server/MailAddress.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/mail/server/MailAddress.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/mail/server/MailAddress.java Sun Mar  4 10:16:54 2007
@@ -23,9 +23,9 @@
  * of the Addresses.
  */
 public class MailAddress extends Address {
-    
+
     private static final long serialVersionUID = 3033256355495000819L;
-    
+
     String mailAddy = null;
 
     public MailAddress(String mAddy) {

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/mail/server/MailServer.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/mail/server/MailServer.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/mail/server/MailServer.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/mail/server/MailServer.java Sun Mar  4 10:16:54 2007
@@ -62,12 +62,13 @@
             Thread.sleep(2000);
         } catch (InterruptedException e1) {
             log.error(e1);
-        } 
+        }
     }
 
     public MailServer(String dir, int popPort, int smtpPort) throws AxisFault {
         try {
-            configurationContext = ConfigurationContextFactory.createConfigurationContextFromFileSystem(dir, null);
+            configurationContext =
+                    ConfigurationContextFactory.createConfigurationContextFromFileSystem(dir, null);
         } catch (Exception e) {
             log.error(e);
         }

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/mail/server/MailSorter.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/mail/server/MailSorter.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/mail/server/MailSorter.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/mail/server/MailSorter.java Sun Mar  4 10:16:54 2007
@@ -16,14 +16,6 @@
 
 package org.apache.axis2.transport.mail.server;
 
-import java.io.ByteArrayInputStream;
-import java.util.ArrayList;
-
-import javax.mail.MessagingException;
-import javax.mail.internet.InternetAddress;
-import javax.mail.internet.MimeMessage;
-import javax.xml.namespace.QName;
-
 import org.apache.axiom.om.impl.builder.StAXBuilder;
 import org.apache.axiom.soap.SOAP11Constants;
 import org.apache.axiom.soap.SOAP12Constants;
@@ -40,6 +32,13 @@
 import org.apache.commons.logging.Log;
 import org.apache.commons.logging.LogFactory;
 
+import javax.mail.MessagingException;
+import javax.mail.internet.InternetAddress;
+import javax.mail.internet.MimeMessage;
+import javax.xml.namespace.QName;
+import java.io.ByteArrayInputStream;
+import java.util.ArrayList;
+
 /**
  * This class will be used to sort the messages into normal messages and mails
  * being sent to the Axis engine. If a mail is to be sent to the engine then a
@@ -76,15 +75,17 @@
         // create and initialize a message context
         try {
             msgContext = ContextFactory.createMessageContext(confContext);
-            msgContext.setTransportIn(confContext.getAxisConfiguration().getTransportIn(new QName(org.apache.axis2.Constants.TRANSPORT_MAIL)));
-            msgContext.setTransportOut(confContext.getAxisConfiguration().getTransportOut(new QName(org.apache.axis2.Constants.TRANSPORT_MAIL)));
+            msgContext.setTransportIn(confContext.getAxisConfiguration().getTransportIn(
+                    new QName(org.apache.axis2.Constants.TRANSPORT_MAIL)));
+            msgContext.setTransportOut(confContext.getAxisConfiguration().getTransportOut(
+                    new QName(org.apache.axis2.Constants.TRANSPORT_MAIL)));
 
             msgContext.setServerSide(true);
             msgContext.setProperty(Constants.CONTENT_TYPE, mimeMessage.getContentType());
             msgContext.setProperty(org.apache.axis2.Constants.Configuration.CHARACTER_SET_ENCODING,
-                    mimeMessage.getEncoding());
+                                   mimeMessage.getEncoding());
             String soapAction = getMailHeader(Constants.HEADER_SOAP_ACTION, mimeMessage);
-            if (soapAction == null){
+            if (soapAction == null) {
                 soapAction = mimeMessage.getSubject();
             }
 
@@ -138,7 +139,8 @@
         } catch (Exception e) {
             try {
                 if (msgContext != null) {
-                    MessageContext faultContext = MessageContextBuilder.createFaultMessageContext(msgContext, e);
+                    MessageContext faultContext =
+                            MessageContextBuilder.createFaultMessageContext(msgContext, e);
 
                     engine.sendFault(faultContext);
                 }

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/mail/server/POP3Worker.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/mail/server/POP3Worker.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/mail/server/POP3Worker.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/mail/server/POP3Worker.java Sun Mar  4 10:16:54 2007
@@ -35,7 +35,8 @@
 public class POP3Worker extends Thread {
     private static final Log log = LogFactory.getLog(POP3Worker.class);
     boolean doneProcess = false;
-    int numDeleted = 0;    // This is a small hack to get the deleting working with the ArrayList. To keep it simple.
+    int numDeleted =
+            0;    // This is a small hack to get the deleting working with the ArrayList. To keep it simple.
     ArrayList messages = new ArrayList();
     private Socket socket;
     private Storage st;
@@ -69,14 +70,17 @@
                 printWriter.println(Constants.OK + "POP3 server signing off");
                 doneProcess = true;
             } else if (input.equals(Constants.STAT)) {
-                printWriter.println(Constants.OK + messages.size() + " 1");    // We take the maildrop size as one.
-            } else if (tokens.get(0).equals(Constants.LIST)) {                               // scan listing
+                printWriter.println(Constants.OK + messages.size() +
+                        " 1");    // We take the maildrop size as one.
+            } else if (tokens.get(0).equals(Constants.LIST))
+            {                               // scan listing
                 if (tokens.size() > 1) {
                     try {
                         int optArg = Integer.parseInt((String) tokens.get(1));
                         int messageArrayIndex = optArg - 1;
 
-                        if ((messageArrayIndex < messages.size()) && (messageArrayIndex >= 0)) {    // that is OK careful with numbering
+                        if ((messageArrayIndex < messages.size()) && (messageArrayIndex >= 0))
+                        {    // that is OK careful with numbering
                             printWriter.println(Constants.OK + messageArrayIndex + 1
                                     + " 120");    // Mail size of 120 is just some number.
                         } else {
@@ -95,7 +99,8 @@
                     for (int i = 0; i < messages.size(); i++) {
                         int messageIndex = i + 1;
 
-                        printWriter.println(messageIndex + " 120");    // List out all the messages with a message size octet of 120
+                        printWriter.println(messageIndex +
+                                " 120");    // List out all the messages with a message size octet of 120
                     }
 
                     printWriter.println(".");
@@ -112,7 +117,8 @@
 
                     m.writeTo(socket.getOutputStream());
 
-                    socket.getOutputStream().write(CR_LF_DOT_CR_LF);    // This is a bit of a hack to get it working. Have to find a bette way to handle this.
+                    socket.getOutputStream()
+                            .write(CR_LF_DOT_CR_LF);    // This is a bit of a hack to get it working. Have to find a bette way to handle this.
                     socket.getOutputStream().flush();
                 } catch (NumberFormatException e) {
                     printWriter.println(Constants.ERR);
@@ -125,7 +131,8 @@
                 String smIndex = (String) tokens.get(1);
 
                 try {
-                    int mIndex = Integer.parseInt(smIndex) - 1 - numDeleted;    // When one mail is deleted the index of the other mails will reduce. Asumed that the delete will occure from bottom up.
+                    int mIndex = Integer.parseInt(smIndex) - 1 -
+                            numDeleted;    // When one mail is deleted the index of the other mails will reduce. Asumed that the delete will occure from bottom up.
 
                     if ((mIndex >= 0) && (mIndex < messages.size())) {
                         messages.remove(mIndex);

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/mail/server/Storage.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/mail/server/Storage.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/mail/server/Storage.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/mail/server/Storage.java Sun Mar  4 10:16:54 2007
@@ -41,7 +41,8 @@
     }
 
     public ArrayList popUserMails(String user) {
-        ArrayList usrMailBox = new ArrayList();    // This will return a emty list when the user has no mails or no mail box.
+        ArrayList usrMailBox =
+                new ArrayList();    // This will return a emty list when the user has no mails or no mail box.
 
         if (users.containsKey(user)) {
             usrMailBox = (ArrayList) users.get(user);

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/tcp/TCPServer.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/tcp/TCPServer.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/tcp/TCPServer.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/tcp/TCPServer.java Sun Mar  4 10:16:54 2007
@@ -107,7 +107,7 @@
             }
 
             TCPServer tcpServer = new TCPServer(Integer.parseInt(args[1]),
-                    repository.getAbsolutePath());
+                                                repository.getAbsolutePath());
 
             System.out.println("[Axis2] Using the Repository " + repository.getAbsolutePath());
             System.out.println("[Axis2] Starting the TCP Server on port " + args[1]);
@@ -195,7 +195,8 @@
         if (hostAddress != null) {
             if (serversocket != null) {
                 // todo this has to fix
-                return new EndpointReference[] {new EndpointReference(hostAddress + "/" + contextPath + serviceName)};
+                return new EndpointReference[]{
+                        new EndpointReference(hostAddress + "/" + contextPath + serviceName)};
             } else {
                 log.debug("Unable to generate EPR for the transport tcp");
                 return null;
@@ -210,8 +211,9 @@
         }
         if (serversocket != null) {
             // todo this has to fix
-            return new EndpointReference[] {new EndpointReference("tcp://" + ip + ":" + (serversocket.getLocalPort())
-                    + "/" + contextPath + "/" + serviceName)};
+            return new EndpointReference[]{
+                    new EndpointReference("tcp://" + ip + ":" + (serversocket.getLocalPort())
+                            + "/" + contextPath + "/" + serviceName)};
         } else {
             log.debug("Unable to generate EPR for the transport tcp");
             return null;

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/tcp/TCPTransportSender.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/tcp/TCPTransportSender.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/tcp/TCPTransportSender.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/tcp/TCPTransportSender.java Sun Mar  4 10:16:54 2007
@@ -105,7 +105,7 @@
         // not available
         if (msgContext.getOperationContext() != null) {
             msgContext.getOperationContext().setProperty(Constants.RESPONSE_WRITTEN,
-                    Constants.VALUE_TRUE);
+                                                         Constants.VALUE_TRUE);
         }
         return InvocationResponse.CONTINUE;
     }

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/tcp/TCPWorker.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/tcp/TCPWorker.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/tcp/TCPWorker.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/transport/tcp/TCPWorker.java Sun Mar  4 10:16:54 2007
@@ -92,7 +92,7 @@
                 }
             } else {
                 throw new AxisFault(Messages.getMessage("unknownTransport",
-                        Constants.TRANSPORT_TCP));
+                                                        Constants.TRANSPORT_TCP));
             }
         } catch (Throwable e) {
             try {
@@ -101,7 +101,8 @@
                 if (msgContext != null) {
                     msgContext.setProperty(MessageContext.TRANSPORT_OUT, socket.getOutputStream());
 
-                    MessageContext faultContext = MessageContextBuilder.createFaultMessageContext(msgContext, e);
+                    MessageContext faultContext =
+                            MessageContextBuilder.createFaultMessageContext(msgContext, e);
 
                     engine.sendFault(faultContext);
                 }

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/util/Base64.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/util/Base64.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/util/Base64.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/util/Base64.java Sun Mar  4 10:16:54 2007
@@ -19,5 +19,5 @@
 /**
  * @deprecated
  */
-public class Base64 extends org.apache.axiom.om.util.Base64{
+public class Base64 extends org.apache.axiom.om.util.Base64 {
 }

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/util/CallbackReceiver.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/util/CallbackReceiver.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/util/CallbackReceiver.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/util/CallbackReceiver.java Sun Mar  4 10:16:54 2007
@@ -45,12 +45,12 @@
     }
 
     public Callback lookupCallback(String msgID) {
-      return (Callback)callbackStore.get(msgID);
+        return (Callback) callbackStore.get(msgID);
     }
 
     public void receive(MessageContext messageCtx) throws AxisFault {
         RelatesTo relatesTO = messageCtx.getOptions().getRelatesTo();
-        if(relatesTO == null){
+        if (relatesTO == null) {
             throw new AxisFault("Cannot identify correct Callback object. RelatesTo is null");
         }
         String messageID = relatesTO.getValue();

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/util/CommandLineOption.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/util/CommandLineOption.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/util/CommandLineOption.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/util/CommandLineOption.java Sun Mar  4 10:16:54 2007
@@ -75,7 +75,7 @@
             return (String) optionValues.get(0);
         } else {
             return null;
-    }
+        }
     }
 
 

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/util/CommandLineOptionConstants.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/util/CommandLineOptionConstants.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/util/CommandLineOptionConstants.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/util/CommandLineOptionConstants.java Sun Mar  4 10:16:54 2007
@@ -18,7 +18,7 @@
 
 public interface CommandLineOptionConstants {
 
-    interface WSDL2JavaConstants{
+    interface WSDL2JavaConstants {
 
         //short option constants
         String WSDL_LOCATION_URI_OPTION = "uri";
@@ -84,7 +84,7 @@
 
     }
 
-    interface Java2WSDLConstants{
+    interface Java2WSDLConstants {
         String OUTPUT_LOCATION_OPTION = "o";
         String OUTPUT_FILENAME_OPTION = "of";
         String CLASSNAME_OPTION = "cn";
@@ -110,7 +110,6 @@
     }
 
     public static final String SOLE_INPUT = "SOLE_INPUT";
-
 
 
 }

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/util/CommandLineOptionParser.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/util/CommandLineOptionParser.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/util/CommandLineOptionParser.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/util/CommandLineOptionParser.java Sun Mar  4 10:16:54 2007
@@ -74,7 +74,7 @@
                     commandLineOption =
                             new CommandLineOption(optionType, optionBundle);
                     commandLineOptions.put(commandLineOption.getOptionType(),
-                            commandLineOption);
+                                           commandLineOption);
                     state = NEW_OPTION;
                     optionType = args[i];
                     optionBundle = null;
@@ -87,7 +87,7 @@
                                     CommandLineOptionConstants.SOLE_INPUT,
                                     args);
                     commandLineOptions.put(commandLineOption.getOptionType(),
-                            commandLineOption);
+                                           commandLineOption);
                     return commandLineOptions;
 
                 } else if (NEW_OPTION == state) {

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/util/DefaultEntityResolver.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/util/DefaultEntityResolver.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/util/DefaultEntityResolver.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/util/DefaultEntityResolver.java Sun Mar  4 10:16:54 2007
@@ -19,7 +19,7 @@
 import org.xml.sax.InputSource;
 
 public class DefaultEntityResolver implements org.xml.sax.EntityResolver {
-     public DefaultEntityResolver() {
+    public DefaultEntityResolver() {
     }
 
     public InputSource resolveEntity(String publicId, String systemId) {

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/util/ExternalPolicySerializer.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/util/ExternalPolicySerializer.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/util/ExternalPolicySerializer.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/util/ExternalPolicySerializer.java Sun Mar  4 10:16:54 2007
@@ -38,11 +38,11 @@
     public void setAssertionsToFilter(List assertions2Filter) {
         this.assertions2Filter = assertions2Filter;
     }
-    
+
     public List getAssertionsToFilter() {
         return assertions2Filter;
     }
-    
+
 
     public void serialize(Policy policy, OutputStream os) {
 
@@ -68,7 +68,7 @@
             // write <wsp:Policy tag
 
             writer.writeStartElement(prefix, Constants.ELEM_POLICY,
-                    Constants.URI_POLICY_NS);
+                                     Constants.URI_POLICY_NS);
             // write xmlns:wsp=".."
             writer.writeNamespace(prefix, Constants.URI_POLICY_NS);
 
@@ -85,19 +85,20 @@
             }
 
             writer.writeStartElement(Constants.ATTR_WSP,
-                    Constants.ELEM_EXACTLYONE, Constants.URI_POLICY_NS);
+                                     Constants.ELEM_EXACTLYONE, Constants.URI_POLICY_NS);
             // write <wsp:ExactlyOne>
 
             List assertionList;
 
             for (Iterator iterator = policy.getAlternatives(); iterator
                     .hasNext();) {
-               
+
                 assertionList = (List) iterator.next();
-                
+
                 // write <wsp:All>
-                writer.writeStartElement(Constants.ATTR_WSP, Constants.ELEM_ALL, Constants.URI_POLICY_NS);
-                
+                writer.writeStartElement(Constants.ATTR_WSP, Constants.ELEM_ALL,
+                                         Constants.URI_POLICY_NS);
+
                 Assertion assertion;
 
                 for (Iterator assertions = assertionList.iterator(); assertions
@@ -109,20 +110,20 @@
                     }
                     assertion.serialize(writer);
                 }
-                
+
                 // write </wsp:All>
                 writer.writeEndElement();
             }
-            
+
             // write </wsp:ExactlyOne>
             writer.writeEndElement();
             // write </wsp:Policy>
             writer.writeEndElement();
-            
+
             writer.flush();
 
         } catch (Exception ex) {
-            
+
             throw new RuntimeException(ex);
 
         }

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/util/JavaUtils.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/util/JavaUtils.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/util/JavaUtils.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/util/JavaUtils.java Sun Mar  4 10:16:54 2007
@@ -30,20 +30,20 @@
      * http://java.sun.com/docs/books/jls/second_edition/html/lexical.doc.html#229308
      * Note that false, true, and null are not strictly keywords; they are literal values,
      * but for the purposes of this array, they can be treated as literals.
-     *    ****** PLEASE KEEP THIS LIST SORTED IN ASCENDING ORDER ******
+     * ****** PLEASE KEEP THIS LIST SORTED IN ASCENDING ORDER ******
      */
     static final String keywords[] =
             {
-                    "abstract",  "assert",       "boolean",    "break",      "byte",      "case",
-                    "catch",     "char",         "class",      "const",     "continue",
-                    "default",   "do",           "double",     "else",      "extends",
-                    "false",     "final",        "finally",    "float",     "for",
-                    "goto",      "if",           "implements", "import",    "instanceof",
-                    "int",       "interface",    "long",       "native",    "new",
-                    "null",      "package",      "private",    "protected", "public",
-                    "return",    "short",        "static",     "strictfp",  "super",
-                    "switch",    "synchronized", "this",       "throw",     "throws",
-                    "transient", "true",         "try",        "void",      "volatile",
+                    "abstract", "assert", "boolean", "break", "byte", "case",
+                    "catch", "char", "class", "const", "continue",
+                    "default", "do", "double", "else", "extends",
+                    "false", "final", "finally", "float", "for",
+                    "goto", "if", "implements", "import", "instanceof",
+                    "int", "interface", "long", "native", "new",
+                    "null", "package", "private", "protected", "public",
+                    "return", "short", "static", "strictfp", "super",
+                    "switch", "synchronized", "this", "throw", "throws",
+                    "transient", "true", "try", "void", "volatile",
                     "while"
             };
 
@@ -77,7 +77,7 @@
      */
     public static boolean isJavaKeyword(String keyword) {
         // None of the java keywords have uppercase characters
-        if(hasUpperCase(keyword)) {
+        if (hasUpperCase(keyword)) {
             return false;
         }
         return (Arrays.binarySearch(keywords, keyword, englishCollator) >= 0);
@@ -85,7 +85,7 @@
 
     /**
      * Check if the word has any uppercase letters
-     * 
+     *
      * @param word
      * @return
      */
@@ -106,8 +106,8 @@
      * Turns a java keyword string into a non-Java keyword string.  (Right now
      * this simply means appending an underscore.)
      */
-    public static String makeNonJavaKeyword(String keyword){
-        return  keywordPrefix + keyword;
+    public static String makeNonJavaKeyword(String keyword) {
+        return keywordPrefix + keyword;
     }
 
     public static String xmlNameToJava(String name) {
@@ -215,11 +215,11 @@
      * @return java identifier
      */
 
-    public static String xmlNameToJavaIdentifier(String name){
+    public static String xmlNameToJavaIdentifier(String name) {
         String javaName = xmlNameToJava(name);
         // convert the first letter to lowercase
-        if ((javaName != null) && (javaName.length() > 0)){
-            javaName = javaName.substring(0,1).toLowerCase() + javaName.substring(1);
+        if ((javaName != null) && (javaName.length() > 0)) {
+            javaName = javaName.substring(0, 1).toLowerCase() + javaName.substring(1);
         }
 
         return javaName;
@@ -227,7 +227,7 @@
 
     /**
      * Tests the String 'value':
-     *   return 'false' if its 'false', '0', or 'no' - else 'true'
+     * return 'false' if its 'false', '0', or 'no' - else 'true'
      * <p/>
      * Follow in 'C' tradition of boolean values:
      * false is specific (0), everything else is true;
@@ -238,62 +238,62 @@
 
     /**
      * Tests the String 'value':
-     *   return 'true' if its 'true', '1', or 'yes' - else 'false'
+     * return 'true' if its 'true', '1', or 'yes' - else 'false'
      */
     public static final boolean isTrueExplicitly(String value) {
-        return value != null  &&
-               (value.equalsIgnoreCase("true")  ||
-                value.equals("1")  ||
-                value.equalsIgnoreCase("yes"));
+        return value != null &&
+                (value.equalsIgnoreCase("true") ||
+                        value.equals("1") ||
+                        value.equalsIgnoreCase("yes"));
     }
 
     /**
      * Tests the Object 'value':
-     *   if its null, return default.
-     *   if its a Boolean, return booleanValue()
-     *   if its an Integer,  return 'false' if its '0' else 'true'
-     *   if its a String, return isTrueExplicitly((String)value).
-     *   All other types return 'true'
+     * if its null, return default.
+     * if its a Boolean, return booleanValue()
+     * if its an Integer,  return 'false' if its '0' else 'true'
+     * if its a String, return isTrueExplicitly((String)value).
+     * All other types return 'true'
      */
     public static final boolean isTrueExplicitly(Object value, boolean defaultVal) {
         if (value == null) {
             return defaultVal;
         }
-        if ( value instanceof Boolean ) {
-            return ((Boolean)value).booleanValue();
+        if (value instanceof Boolean) {
+            return ((Boolean) value).booleanValue();
         }
-        if ( value instanceof Integer ) {
-            return ((Integer)value).intValue() != 0;
+        if (value instanceof Integer) {
+            return ((Integer) value).intValue() != 0;
         }
-        if ( value instanceof String ) {
-            return isTrueExplicitly( (String)value );
+        if (value instanceof String) {
+            return isTrueExplicitly((String) value);
         }
         return true;
     }
-    
+
     public static final boolean isTrueExplicitly(Object value) {
         return isTrueExplicitly(value, false);
     }
 
     /**
      * Tests the Object 'value':
-     *   if its null, return default.
-     *   if its a Boolean, return booleanValue()
-     *   if its an Integer,  return 'false' if its '0' else 'true'
-     *   if its a String, return 'false' if its 'false', 'no', or '0' - else 'true'
-     *   All other types return 'true'
+     * if its null, return default.
+     * if its a Boolean, return booleanValue()
+     * if its an Integer,  return 'false' if its '0' else 'true'
+     * if its a String, return 'false' if its 'false', 'no', or '0' - else 'true'
+     * All other types return 'true'
      */
     public static final boolean isTrue(Object value, boolean defaultVal) {
         return !isFalseExplicitly(value, !defaultVal);
     }
-    
+
     public static final boolean isTrue(Object value) {
         return isTrue(value, false);
     }
-    
+
     /**
      * Tests the String 'value':
-     *   return 'true' if its 'false', '0', or 'no' - else 'false'
+     * return 'true' if its 'false', '0', or 'no' - else 'false'
      * <p/>
      * Follow in 'C' tradition of boolean values:
      * false is specific (0), everything else is true;
@@ -304,55 +304,55 @@
 
     /**
      * Tests the String 'value':
-     *   return 'true' if its null, 'false', '0', or 'no' - else 'false'
+     * return 'true' if its null, 'false', '0', or 'no' - else 'false'
      */
     public static final boolean isFalseExplicitly(String value) {
-        return value == null  ||
-               value.equalsIgnoreCase("false")  ||
-               value.equals("0")  ||
-               value.equalsIgnoreCase("no");
+        return value == null ||
+                value.equalsIgnoreCase("false") ||
+                value.equals("0") ||
+                value.equalsIgnoreCase("no");
     }
-    
+
     /**
      * Tests the Object 'value':
-     *   if its null, return default.
-     *   if its a Boolean, return !booleanValue()
-     *   if its an Integer,  return 'true' if its '0' else 'false'
-     *   if its a String, return isFalseExplicitly((String)value).
-     *   All other types return 'false'
+     * if its null, return default.
+     * if its a Boolean, return !booleanValue()
+     * if its an Integer,  return 'true' if its '0' else 'false'
+     * if its a String, return isFalseExplicitly((String)value).
+     * All other types return 'false'
      */
     public static final boolean isFalseExplicitly(Object value, boolean defaultVal) {
         if (value == null) {
             return defaultVal;
         }
-        if ( value instanceof Boolean ) {
-            return !((Boolean)value).booleanValue();
+        if (value instanceof Boolean) {
+            return !((Boolean) value).booleanValue();
         }
-        if ( value instanceof Integer ) {
-            return ((Integer)value).intValue() == 0;
+        if (value instanceof Integer) {
+            return ((Integer) value).intValue() == 0;
         }
-        if ( value instanceof String ) {
-            return isFalseExplicitly( (String)value );
+        if (value instanceof String) {
+            return isFalseExplicitly((String) value);
         }
         return false;
     }
-    
+
     public static final boolean isFalseExplicitly(Object value) {
         return isFalseExplicitly(value, true);
     }
 
     /**
      * Tests the Object 'value':
-     *   if its null, return default.
-     *   if its a Boolean, return booleanValue()
-     *   if its an Integer,  return 'false' if its '0' else 'true'
-     *   if its a String, return 'false' if its 'false', 'no', or '0' - else 'true'
-     *   All other types return 'true'
+     * if its null, return default.
+     * if its a Boolean, return booleanValue()
+     * if its an Integer,  return 'false' if its '0' else 'true'
+     * if its a String, return 'false' if its 'false', 'no', or '0' - else 'true'
+     * All other types return 'true'
      */
     public static final boolean isFalse(Object value, boolean defaultVal) {
         return isFalseExplicitly(value, defaultVal);
     }
-    
+
     public static final boolean isFalse(Object value) {
         return isFalse(value, true);
     }
@@ -448,7 +448,7 @@
         } else if (primitive == char.class) {
             return java.lang.Character.class;
         }
-        
+
         return null;
     }
 
@@ -462,7 +462,7 @@
      *         character
      */
     public static int indexOfIgnoreCase(final String string,
-            final String search) {
+                                        final String search) {
         int index = -1;
         final int stringLength = string.length();
         final int testLength = search.length();
@@ -481,7 +481,7 @@
                             break;
                         }
                     }
-                    if( -1 != index ){
+                    if (-1 != index) {
                         break;
                     }
                 }

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/util/Loader.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/util/Loader.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/util/Loader.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/util/Loader.java Sun Mar  4 10:16:54 2007
@@ -57,7 +57,8 @@
             // classloader that loaded this class.
             classLoader = getTCL();
             if (classLoader != null) {
-                log.debug("Trying to find [" + resource + "] using " + classLoader + " class loader.");
+                log.debug("Trying to find [" + resource + "] using " + classLoader +
+                        " class loader.");
                 url = classLoader.getResource(resource);
                 if (url != null) {
                     return url;
@@ -66,7 +67,7 @@
         } catch (Throwable t) {
             log.warn("Caught Exception while in Loader.getResource. This may be innocuous.", t);
         }
-    
+
         // Last ditch attempt: get the resource from the class path. It
         // may be the case that clazz was loaded by the Extentsion class
         // loader which the parent of the system class loader. Hence the
@@ -74,7 +75,7 @@
         log.debug("Trying to find [" + resource + "] using ClassLoader.getSystemResource().");
         return ClassLoader.getSystemResource(resource);
     }
-    
+
 
     /**
      * Gets the resource with the specified class loader.
@@ -84,7 +85,8 @@
      * @return Returns URL.
      * @throws ClassNotFoundException
      */
-    static public URL getResource(ClassLoader loader, String resource) throws ClassNotFoundException {
+    static public URL getResource(ClassLoader loader, String resource)
+            throws ClassNotFoundException {
         URL url = null;
         try {
             if (loader != null) {
@@ -108,7 +110,7 @@
      * @throws InvocationTargetException
      */
     static public ClassLoader getTCL() throws IllegalAccessException, InvocationTargetException {
-        return (ClassLoader)AccessController.doPrivileged(new PrivilegedAction() {
+        return (ClassLoader) AccessController.doPrivileged(new PrivilegedAction() {
             public Object run() {
                 return Thread.currentThread().getContextClassLoader();
             }
@@ -125,11 +127,11 @@
      */
     static public Class loadClass(ClassLoader loader, String clazz) throws ClassNotFoundException {
         try {
-            if(loader != null) {
+            if (loader != null) {
                 Class c = loader.loadClass(clazz);
                 if (c != null) {
                     return c;
-            }
+                }
             }
         } catch (Throwable e) {
             log.debug(e);
@@ -149,13 +151,13 @@
      */
     static public Class loadClass(String clazz) throws ClassNotFoundException {
         try {
-            ClassLoader tcl = getTCL();    
-            
-            if(tcl != null) {
+            ClassLoader tcl = getTCL();
+
+            if (tcl != null) {
                 Class c = tcl.loadClass(clazz);
                 if (c != null) {
                     return c;
-            }
+                }
             }
         } catch (Throwable e) {
             log.debug(e);

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/util/LoggingControl.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/util/LoggingControl.java?view=diff&rev=514453&r1=514452&r2=514453
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/util/LoggingControl.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/util/LoggingControl.java Sun Mar  4 10:16:54 2007
@@ -22,18 +22,17 @@
  * do most providers of the Common's logging API at the cost of runtime
  * flexibility.
  */
-public class LoggingControl
-{
-  /**
-   * If this flag is set to false then debug messages will not be logged,
-   * irrespective of the level set for the logger itself.  This can only
-   * be changed as the result of a JVM restart or a purge and reloading
-   * of this class.
-   * 
-   * Usage: if (LoggingControl.debugLoggingAllowed && log.isDebugEnabled())...
-   *        or
-   *        if (LoggingControl.debugLoggingAllowed && log.isTraceEnabled())...
-   */
-  public static final boolean debugLoggingAllowed =
-    (System.getProperty("Axis2.prohibitDebugLogging") == null);
+public class LoggingControl {
+    /**
+     * If this flag is set to false then debug messages will not be logged,
+     * irrespective of the level set for the logger itself.  This can only
+     * be changed as the result of a JVM restart or a purge and reloading
+     * of this class.
+     * <p/>
+     * Usage: if (LoggingControl.debugLoggingAllowed && log.isDebugEnabled())...
+     * or
+     * if (LoggingControl.debugLoggingAllowed && log.isTraceEnabled())...
+     */
+    public static final boolean debugLoggingAllowed =
+            (System.getProperty("Axis2.prohibitDebugLogging") == null);
 }



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