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 di...@apache.org on 2007/02/25 21:14:45 UTC

svn commit: r511588 [8/8] - in /webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2: ./ addressing/ addressing/wsdl/ builder/ client/ context/ dataretrieval/ dataretrieval/client/ deployment/ deployment/resolver/ deployment/util/ descripti...

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/util/ThreadContextMigratorUtil.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/util/ThreadContextMigratorUtil.java?view=diff&rev=511588&r1=511587&r2=511588
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/util/ThreadContextMigratorUtil.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/util/ThreadContextMigratorUtil.java Sun Feb 25 12:14:38 2007
@@ -29,8 +29,7 @@
  * model-level implementations (e.g. the Axis2 JAX-WS code) to invoke the
  * ThreadContextMigrators. 
  */
-public class ThreadContextMigratorUtil
-{  
+public class ThreadContextMigratorUtil {
   /**
    * Register a new ThreadContextMigrator.
    * 
@@ -40,12 +39,10 @@
    *                                    the list of migrators.
    * @param migrator
    */
-  public static void addThreadContextMigrator(ConfigurationContext configurationContext, String threadContextMigratorListID, ThreadContextMigrator migrator)
-  {
+    public static void addThreadContextMigrator(ConfigurationContext configurationContext, String threadContextMigratorListID, ThreadContextMigrator migrator) {
     List migratorList = (List)configurationContext.getProperty(threadContextMigratorListID);
 
-    if (migratorList == null)
-    {
+        if (migratorList == null) {
       migratorList = new LinkedList();
       configurationContext.setProperty(threadContextMigratorListID, migratorList);
     }
@@ -56,28 +53,24 @@
   /**
    * Activate any registered ThreadContextMigrators to move context info
    * to the thread of execution.
+     *
    * @param threadContextMigratorListID The name of the property in the
    *                                    ConfigurationContext that contains
    *                                    the list of migrators.
    * @param msgContext
-   * 
    * @throws AxisFault
    */
   public static void performMigrationToThread(String threadContextMigratorListID, MessageContext msgContext)
-  throws AxisFault
-  {
-    if (msgContext == null)
-    {
+            throws AxisFault {
+        if (msgContext == null) {
       return;
     }
       
     List migratorList = (List)msgContext.getConfigurationContext().getProperty(threadContextMigratorListID);
     
-    if (migratorList != null)
-    {
+        if (migratorList != null) {
       ListIterator threadContextMigrators = migratorList.listIterator();
-      while (threadContextMigrators.hasNext())
-      {
+            while (threadContextMigrators.hasNext()) {
         ((ThreadContextMigrator)threadContextMigrators.next()).migrateContextToThread(msgContext);
       }
     }
@@ -92,20 +85,16 @@
    *                                    the list of migrators.
    * @param msgContext
    */
-  public static void performThreadCleanup(String threadContextMigratorListID, MessageContext msgContext)
-  {
-    if (msgContext == null)
-    {
+    public static void performThreadCleanup(String threadContextMigratorListID, MessageContext msgContext) {
+        if (msgContext == null) {
       return;
     }
       
     List migratorList = (List)msgContext.getConfigurationContext().getProperty(threadContextMigratorListID);
     
-    if (migratorList != null)
-    {
+        if (migratorList != null) {
       ListIterator threadContextMigrators = migratorList.listIterator();
-      while (threadContextMigrators.hasNext())
-      {
+            while (threadContextMigrators.hasNext()) {
         ((ThreadContextMigrator)threadContextMigrators.next()).cleanupThread(msgContext);
       }
     }
@@ -122,20 +111,16 @@
    * @throws AxisFault
    */
   public static void performMigrationToContext(String threadContextMigratorListID, MessageContext msgContext)
-  throws AxisFault
-  {
-    if (msgContext == null)
-    {
+            throws AxisFault {
+        if (msgContext == null) {
       return;
     }
       
     List migratorList = (List)msgContext.getConfigurationContext().getProperty(threadContextMigratorListID);
 
-    if (migratorList != null)
-    {
+        if (migratorList != null) {
       ListIterator threadContextMigrators = migratorList.listIterator();
-      while (threadContextMigrators.hasNext())
-      {
+            while (threadContextMigrators.hasNext()) {
         ((ThreadContextMigrator)threadContextMigrators.next()).migrateThreadToContext(msgContext);
       }
     }
@@ -150,20 +135,16 @@
    *                                    the list of migrators.
    * @param msgContext
    */
-  public static void performContextCleanup(String threadContextMigratorListID, MessageContext msgContext)
-  {
-    if (msgContext == null)
-    {
+    public static void performContextCleanup(String threadContextMigratorListID, MessageContext msgContext) {
+        if (msgContext == null) {
       return;
     }
       
     List migratorList = (List)msgContext.getConfigurationContext().getProperty(threadContextMigratorListID);
 
-    if (migratorList != null)
-    {
+        if (migratorList != null) {
       ListIterator threadContextMigrators = migratorList.listIterator();
-      while (threadContextMigrators.hasNext())
-      {
+            while (threadContextMigrators.hasNext()) {
         ((ThreadContextMigrator)threadContextMigrators.next()).cleanupContext(msgContext);
       }
     }

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/util/UUIDGenerator.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/util/UUIDGenerator.java?view=diff&rev=511588&r1=511587&r2=511588
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/util/UUIDGenerator.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/util/UUIDGenerator.java Sun Feb 25 12:14:38 2007
@@ -16,13 +16,6 @@
 
 package org.apache.axis2.util;
 
-import java.net.InetAddress;
-import java.net.UnknownHostException;
-import java.security.MessageDigest;
-import java.security.NoSuchAlgorithmException;
-import java.util.Date;
-import java.util.Random;
-
 /**
  * @deprecated
  */

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/util/Utils.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/util/Utils.java?view=diff&rev=511588&r1=511587&r2=511588
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/util/Utils.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/util/Utils.java Sun Feb 25 12:14:38 2007
@@ -17,19 +17,18 @@
 
 package org.apache.axis2.util;
 
-import java.io.File;
-import java.util.HashMap;
-import java.util.Iterator;
-
-import javax.xml.namespace.QName;
-
 import org.apache.axiom.om.util.UUIDGenerator;
 import org.apache.axiom.soap.SOAPEnvelope;
 import org.apache.axiom.soap.SOAPFault;
 import org.apache.axis2.AxisFault;
 import org.apache.axis2.Constants;
 import org.apache.axis2.cluster.ClusterManager;
-import org.apache.axis2.context.*;
+import org.apache.axis2.context.ConfigurationContext;
+import org.apache.axis2.context.ConfigurationContextFactory;
+import org.apache.axis2.context.ContextFactory;
+import org.apache.axis2.context.MessageContext;
+import org.apache.axis2.context.ServiceContext;
+import org.apache.axis2.context.ServiceGroupContext;
 import org.apache.axis2.description.AxisModule;
 import org.apache.axis2.description.AxisOperation;
 import org.apache.axis2.description.AxisService;
@@ -48,6 +47,11 @@
 import org.apache.axis2.receivers.RawXMLINOutMessageReceiver;
 import org.apache.axis2.wsdl.WSDLConstants;
 
+import javax.xml.namespace.QName;
+import java.io.File;
+import java.util.HashMap;
+import java.util.Iterator;
+
 public class Utils {
     public static void addHandler(Flow flow, Handler handler, String phaseName) {
         HandlerDescription handlerDesc = new HandlerDescription();
@@ -60,8 +64,8 @@
     }
 
     /**
-     * @deprecated (post 1.1 branch)
      * @see org.apache.axis2.util.MessageContextBuilder.createOutMessageContext()
+     * @deprecated (post1.1branch)
      */
     public static MessageContext createOutMessageContext(MessageContext inMessageContext)
             throws AxisFault {
@@ -380,7 +384,7 @@
      * Get an AxisFault object to represent the SOAPFault in the SOAPEnvelope attached
      * to the provided MessageContext. This first check for an already extracted AxisFault
      * and otherwise does a simple extract.
-     * 
+     * <p/>
      * MUST NOT be passed a MessageContext which does not contain a SOAPFault
      * 
      * @param messageContext

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/util/XMLChar.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/util/XMLChar.java?view=diff&rev=511588&r1=511587&r2=511588
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/util/XMLChar.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/util/XMLChar.java Sun Feb 25 12:14:38 2007
@@ -21,7 +21,7 @@
  * in this class can be used to verify that a character is a valid
  * XML character or if the character is a space, name start, or name
  * character.
- * <p>
+ * <p/>
  * A series of convenience methods are supplied to ease the burden
  * of the developer. Because inlining the checks can improve per
  * character performance, the tables of character properties are
@@ -30,7 +30,6 @@
  * <code>MASK_VALID</code>), yields the same results as calling the
  * convenience methods. There is one exception: check the comments
  * for the <code>isValid</code> method for details.
- *
  */
 public class XMLChar {
 
@@ -38,22 +37,34 @@
     // Constants
     //
 
-    /** Character flags. */
+    /**
+     * Character flags.
+     */
     private static final byte[] CHARS = new byte[1 << 16];
 
-    /** Valid character mask. */
+    /**
+     * Valid character mask.
+     */
     public static final int MASK_VALID = 0x01;
 
-    /** Space character mask. */
+    /**
+     * Space character mask.
+     */
     public static final int MASK_SPACE = 0x02;
 
-    /** Name start character mask. */
+    /**
+     * Name start character mask.
+     */
     public static final int MASK_NAME_START = 0x04;
 
-    /** Name character mask. */
+    /**
+     * Name character mask.
+     */
     public static final int MASK_NAME = 0x08;
 
-    /** Pubid character mask. */
+    /**
+     * Pubid character mask.
+     */
     public static final int MASK_PUBID = 0x10;
 
     /**
@@ -61,15 +72,19 @@
      * be considered the start of markup, such as '&lt;' and '&amp;'.
      * The various newline characters are considered special as well.
      * All other valid XML characters can be considered content.
-     * <p>
+     * <p/>
      * This is an optimization for the inner loop of character scanning.
      */
     public static final int MASK_CONTENT = 0x20;
 
-    /** NCName start character mask. */
+    /**
+     * NCName start character mask.
+     */
     public static final int MASK_NCNAME_START = 0x40;
 
-    /** NCName character mask. */
+    /**
+     * NCName character mask.
+     */
     public static final int MASK_NCNAME = 0x80;
 
     //
@@ -389,7 +404,7 @@
     /**
      * Returns true if the specified character is valid. This method
      * also checks the surrogate character range from 0x10000 to 0x10FFFF.
-     * <p>
+     * <p/>
      * If the program chooses to apply the mask directly to the
      * <code>CHARS</code> array, then they are responsible for checking
      * the surrogate character range.
@@ -517,11 +532,13 @@
      * @return true if name is a valid Name
      */
     public static boolean isValidName(String name) {
-        if (name.length() == 0)
+        if (name.length() == 0) {
             return false;
+        }
         char ch = name.charAt(0);
-        if(!isNameStart(ch))
+        if (!isNameStart(ch)) {
            return false;
+        }
         for (int i = 1; i < name.length(); i++ ) {
            ch = name.charAt(i);
            if(!isName(ch) ){
@@ -544,11 +561,13 @@
      * @return true if name is a valid NCName
      */
     public static boolean isValidNCName(String ncName) {
-        if (ncName.length() == 0)
+        if (ncName.length() == 0) {
             return false;
+        }
         char ch = ncName.charAt(0);
-        if(!isNCNameStart(ch))
+        if (!isNCNameStart(ch)) {
            return false;
+        }
         for (int i = 1; i < ncName.length(); i++ ) {
            ch = ncName.charAt(i);
            if(!isNCName(ch) ){
@@ -569,8 +588,9 @@
      * @return true if nmtoken is a valid Nmtoken
      */
     public static boolean isValidNmtoken(String nmtoken) {
-        if (nmtoken.length() == 0)
+        if (nmtoken.length() == 0) {
             return false;
+        }
         for (int i = 0; i < nmtoken.length(); i++ ) {
            char ch = nmtoken.charAt(i);
            if(  ! isName( ch ) ){

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/util/XMLPrettyPrinter.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/util/XMLPrettyPrinter.java?view=diff&rev=511588&r1=511587&r2=511588
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/util/XMLPrettyPrinter.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/util/XMLPrettyPrinter.java Sun Feb 25 12:14:38 2007
@@ -28,7 +28,6 @@
  *   An XML pretty printer based on jtidy (http://sourceforge.net/projects/jtidy)
  *   The Jtidy jar needs to be in classpath for this to work and can be found at
  *   http://sourceforge.net/project/showfiles.php?group_id=13153
- * 
  */
 public class XMLPrettyPrinter {
 

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/util/XMLUtils.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/util/XMLUtils.java?view=diff&rev=511588&r1=511587&r2=511588
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/util/XMLUtils.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/util/XMLUtils.java Sun Feb 25 12:14:38 2007
@@ -17,11 +17,10 @@
 package org.apache.axis2.util;
 
 import com.ibm.wsdl.Constants;
-
+import org.apache.axiom.om.OMAbstractFactory;
 import org.apache.axiom.om.OMElement;
-import org.apache.axiom.om.OMNode;
 import org.apache.axiom.om.OMFactory;
-import org.apache.axiom.om.OMAbstractFactory;
+import org.apache.axiom.om.OMNode;
 import org.apache.axiom.om.impl.builder.StAXOMBuilder;
 import org.apache.axiom.om.util.Base64;
 import org.apache.axiom.om.util.StAXUtils;
@@ -44,8 +43,8 @@
 import javax.xml.parsers.ParserConfigurationException;
 import javax.xml.parsers.SAXParser;
 import javax.xml.parsers.SAXParserFactory;
-import javax.xml.stream.XMLStreamReader;
 import javax.xml.stream.XMLStreamException;
+import javax.xml.stream.XMLStreamReader;
 import javax.xml.transform.Result;
 import javax.xml.transform.Source;
 import javax.xml.transform.Transformer;
@@ -57,8 +56,8 @@
 import java.io.ByteArrayOutputStream;
 import java.io.IOException;
 import java.io.InputStream;
-import java.io.UnsupportedEncodingException;
 import java.io.Reader;
+import java.io.UnsupportedEncodingException;
 import java.net.HttpURLConnection;
 import java.net.MalformedURLException;
 import java.net.ProtocolException;
@@ -96,12 +95,10 @@
      *                         alone.
      * @param namespaceAware true if we want a namespace-aware parser
      * @param validating true if we want a validating parser
-     *
      */
     public static void initSAXFactory(String factoryClassName,
                                       boolean namespaceAware,
-                                      boolean validating)
-    {
+                                      boolean validating) {
         if (factoryClassName != null) {
             try {
                 saxFactory = (SAXParserFactory)Loader.loadClass(factoryClassName).
@@ -145,10 +142,13 @@
 
     /** 
      * Returns a SAX parser for reuse.
+     *
      * @param parser A SAX parser that is available for reuse
      */
     public static void releaseSAXParser(SAXParser parser) {
-        if(!tryReset) return;
+        if (!tryReset) {
+            return;
+        }
 
         //Free up possible ref. held by past contenthandler.
         try{
@@ -157,22 +157,22 @@
                 synchronized (XMLUtils.class ) {
                     saxParsers.push(parser);
                 }
-            }
-            else {
+            } else {
                 tryReset= false;
             }
         } catch (org.xml.sax.SAXException e) {
             tryReset= false;
         }
     }
+
     /**
      * Gets an empty new Document.
+     *
      * @return Returns Document.
      * @throws ParserConfigurationException if construction problems occur
      */
     public static Document newDocument() 
-         throws ParserConfigurationException
-    {
+            throws ParserConfigurationException {
         synchronized (dbf) {
             return dbf.newDocumentBuilder().newDocument();
         }
@@ -180,14 +180,14 @@
 
     /**
      * Gets a new Document read from the input source.
+     *
      * @return Returns Document.
      * @throws ParserConfigurationException if construction problems occur
      * @throws SAXException if the document has xml sax problems
      * @throws IOException if i/o exceptions occur
      */
     public static Document newDocument(InputSource inp)
-        throws ParserConfigurationException, SAXException, IOException
-    {
+            throws ParserConfigurationException, SAXException, IOException {
         DocumentBuilder db;
         synchronized (dbf) {
             db = dbf.newDocumentBuilder();
@@ -199,27 +199,27 @@
 
     /**
      * Gets a new Document read from the input stream
+     *
      * @return Returns Document.
      * @throws ParserConfigurationException if construction problems occur
      * @throws SAXException if the document has xml sax problems
      * @throws IOException if i/o exceptions occur
      */
     public static Document newDocument(InputStream inp) 
-        throws ParserConfigurationException, SAXException, IOException 
-    {
+            throws ParserConfigurationException, SAXException, IOException {
         return XMLUtils.newDocument(new InputSource(inp));
     } 
 
     /**
      * Gets a new Document read from the indicated uri
+     *
      * @return Returns Document.
      * @throws ParserConfigurationException if construction problems occur
      * @throws SAXException if the document has xml sax problems
      * @throws IOException if i/o exceptions occur
      */
     public static Document newDocument(String uri) 
-        throws ParserConfigurationException, SAXException, IOException 
-    {
+            throws ParserConfigurationException, SAXException, IOException {
         // call the authenticated version as there might be 
         // username/password info embeded in the uri.
         return XMLUtils.newDocument(uri, null, null);
@@ -228,6 +228,7 @@
     /**
      * Creates a new document from the given URI. Uses the username and password
      * if the URI requires authentication.
+     *
      * @param uri the resource to get
      * @param username basic auth username
      * @param password basic auth password
@@ -236,8 +237,7 @@
      * @throws IOException if i/o exceptions occur
      */ 
     public static Document newDocument(String uri, String username, String password)
-        throws ParserConfigurationException, SAXException, IOException
-     {
+            throws ParserConfigurationException, SAXException, IOException {
          InputSource ins = XMLUtils.getInputSourceFromURI(uri, username, password);
          Document doc = XMLUtils.newDocument(ins);
          // Close the Stream
@@ -271,7 +271,9 @@
         while (e != null && (e.getNodeType() == Node.ELEMENT_NODE)) {
             Attr attr =
                 ((Element)e).getAttributeNodeNS(Constants.NS_URI_XMLNS, prefix);
-            if (attr != null) return attr.getValue();
+            if (attr != null) {
+                return attr.getValue();
+            }
             e = e.getParentNode();
         }
         return null;
@@ -284,15 +286,17 @@
      * @return Returns a QName generated from the given string representation.
      */
     public static QName getQNameFromString(String str, Node e) {
-        if (str == null || e == null)
+        if (str == null || e == null) {
             return null;
+        }
 
         int idx = str.indexOf(':');
         if (idx > -1) {
             String prefix = str.substring(0, idx);
             String ns = getNamespace(prefix, e);
-            if (ns == null)
+            if (ns == null) {
                 return null;
+            }
             return new QName(ns, str.substring(idx + 1));
         } else {
             return new QName("", str);
@@ -303,8 +307,7 @@
      * Returns a string for a particular QName, mapping a new prefix
      * if necessary.
      */
-    public static String getStringForQName(QName qname, Element e)
-    {
+    public static String getStringForQName(QName qname, Element e) {
         String uri = qname.getNamespaceURI();
         String prefix = getPrefix(uri, e);
         if (prefix == null) {
@@ -340,7 +343,8 @@
     while (tempNode != null) {
       switch (tempNode.getNodeType()) {
         case Node.TEXT_NODE :
-        case Node.CDATA_SECTION_NODE : charData = (CharacterData)tempNode;
+                case Node.CDATA_SECTION_NODE:
+                    charData = (CharacterData) tempNode;
                                        strBuf.append(charData.getData());
                                        break;
       }
@@ -349,8 +353,7 @@
     return strBuf.toString();
   }
     
-    public static class ParserErrorHandler implements ErrorHandler
-    {
+    public static class ParserErrorHandler implements ErrorHandler {
         /**
          * Returns a string describing parse exception details
          */
@@ -394,14 +397,13 @@
     }
 
 
-
     /**
      * Utility to get the bytes at a protected uri
-     * 
+     * <p/>
      * Retrieves the URL if a username and password are provided.
      * The java.net.URL class does not do Basic Authentication, so we have to
      * do it manually in this routine.
-     * 
+     * <p/>
      * If no username is provided, creates an InputSource from the uri
      * and lets the InputSource go fetch the contents.
      * 
@@ -412,8 +414,7 @@
     private static InputSource getInputSourceFromURI(String uri,
                                                      String username,
                                                      String password)
-        throws IOException, ProtocolException, UnsupportedEncodingException
-    {
+            throws IOException, ProtocolException, UnsupportedEncodingException {
         URL wsdlurl = null;
         try {
             wsdlurl = new URL(uri);
@@ -485,19 +486,22 @@
      */ 
     public static Node findNode(Node node, QName name){
         if(name.getNamespaceURI().equals(node.getNamespaceURI()) && 
-           name.getLocalPart().equals(node.getLocalName()))
+                name.getLocalPart().equals(node.getLocalName())) {
             return node;
+        }
         NodeList children = node.getChildNodes();
         for(int i=0;i<children.getLength();i++){
             Node ret = findNode(children.item(i), name);
-            if(ret != null)
+            if (ret != null) {
                 return ret;
         }
+        }
         return null;
     }
     
     /**
      * Converts a given DOM Element to an OMElement.
+     *
      * @param element
      * @return Returns OMElement.
      * @throws Exception
@@ -525,6 +529,7 @@
 
     /**
      * Converts a given OMElement to a DOM Element.
+     *
      * @param element
      * @return Returns Element.
      * @throws Exception
@@ -546,6 +551,7 @@
      * @param inputStream
      * @return
      * @throws javax.xml.stream.XMLStreamException
+     *
      */
     public static OMNode toOM(InputStream inputStream) throws XMLStreamException {
         XMLStreamReader xmlReader = StAXUtils

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/util/threadpool/ThreadPool.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/util/threadpool/ThreadPool.java?view=diff&rev=511588&r1=511587&r2=511588
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/util/threadpool/ThreadPool.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/util/threadpool/ThreadPool.java Sun Feb 25 12:14:38 2007
@@ -21,13 +21,14 @@
 import edu.emory.mathcs.backport.java.util.concurrent.SynchronousQueue;
 import edu.emory.mathcs.backport.java.util.concurrent.ThreadPoolExecutor;
 import edu.emory.mathcs.backport.java.util.concurrent.TimeUnit;
-import java.security.PrivilegedActionException;
-import java.security.PrivilegedExceptionAction;
 import org.apache.axis2.AxisFault;
 import org.apache.axis2.i18n.Messages;
 import org.apache.axis2.java.security.AccessController;
 import org.apache.commons.logging.Log;
 import org.apache.commons.logging.LogFactory;
+
+import java.security.PrivilegedActionException;
+import java.security.PrivilegedExceptionAction;
 
 /**
  * This the thread pool for axis2. This class will be used a singleton

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/wsdl/WSDLUtil.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/wsdl/WSDLUtil.java?view=diff&rev=511588&r1=511587&r2=511588
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/wsdl/WSDLUtil.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/wsdl/WSDLUtil.java Sun Feb 25 12:14:38 2007
@@ -25,6 +25,7 @@
     /**
      * returns whether the given mep uri is one of the
      * input meps
+     *
      * @param mep
      */
     public static boolean isInputPresentForMEP(String mep) {
@@ -38,6 +39,7 @@
 
     /**
      * returns whether the given mep URI is one of the output meps
+     *
      * @param MEP
      */
     public static boolean isOutputPresentForMEP(String MEP) {
@@ -51,15 +53,16 @@
 
     /**
      *  part names are not unique across messages. Hence
-     we need some way of making the part name a unique
-     one (due to the fact that the type mapper
-     is a global list of types).
-     The seemingly best way to do that is to
-     specify a namespace for the part QName reference which
-     is stored in the  list. This part qname is
-     temporary and should not be used with it's
-     namespace URI (which happened to be the operation name)
-     with _input (or a similar suffix) attached to it
+     * we need some way of making the part name a unique
+     * one (due to the fact that the type mapper
+     * is a global list of types).
+     * The seemingly best way to do that is to
+     * specify a namespace for the part QName reference which
+     * is stored in the  list. This part qname is
+     * temporary and should not be used with it's
+     * namespace URI (which happened to be the operation name)
+     * with _input (or a similar suffix) attached to it
+     *
      * @param opName
      * @param suffix
      * @param partName



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