You are viewing a plain text version of this content. The canonical link for it is here.
Posted to axis-cvs@ws.apache.org by di...@apache.org on 2005/02/20 04:01:04 UTC

svn commit: r154468 [4/6] - in webservices/axis/trunk/java/modules/om/src: java/org/apache/axis/om/ java/org/apache/axis/om/impl/llom/ java/org/apache/axis/om/impl/llom/builder/ java/org/apache/axis/om/impl/llom/exception/ java/org/apache/axis/om/impl/llom/factory/ java/org/apache/axis/om/impl/llom/serialize/ java/org/apache/axis/om/impl/llom/traverse/ test-resources/ test-resources/badsoap/ test-resources/soap/ test/org/apache/axis/om/ test/org/apache/axis/om/factory/ test/org/apache/axis/om/impl/builder/ test/org/apache/axis/om/impl/serializer/ test/org/apache/axis/om/impl/streamwrapper/ test/org/apache/axis/om/impl/traverse/

Modified: webservices/axis/trunk/java/modules/om/src/java/org/apache/axis/om/impl/llom/serialize/StreamWriterToContentHandlerConverter.java
URL: http://svn.apache.org/viewcvs/webservices/axis/trunk/java/modules/om/src/java/org/apache/axis/om/impl/llom/serialize/StreamWriterToContentHandlerConverter.java?view=diff&r1=154467&r2=154468
==============================================================================
--- webservices/axis/trunk/java/modules/om/src/java/org/apache/axis/om/impl/llom/serialize/StreamWriterToContentHandlerConverter.java (original)
+++ webservices/axis/trunk/java/modules/om/src/java/org/apache/axis/om/impl/llom/serialize/StreamWriterToContentHandlerConverter.java Sat Feb 19 19:00:47 2005
@@ -1,19 +1,18 @@
 /*
  * Copyright 2004,2005 The Apache Software Foundation.
- * 
+ *
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.
  * You may obtain a copy of the License at
- * 
+ *
  *      http://www.apache.org/licenses/LICENSE-2.0
- * 
+ *
  * Unless required by applicable law or agreed to in writing, software
  * distributed under the License is distributed on an "AS IS" BASIS,
  * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
- 
 package org.apache.axis.om.impl.llom.serialize;
 
 import org.apache.commons.logging.Log;
@@ -26,23 +25,59 @@
 import javax.xml.stream.XMLStreamException;
 import javax.xml.stream.XMLStreamWriter;
 
+/**
+ * Class StreamWriterToContentHandlerConverter
+ */
 public class StreamWriterToContentHandlerConverter implements ContentHandler {
+    /**
+     * Field log
+     */
     private Log log = LogFactory.getLog(getClass());
+
+    /**
+     * Field writer
+     */
     private XMLStreamWriter writer;
 
+    /**
+     * Constructor StreamWriterToContentHandlerConverter
+     *
+     * @param writer
+     */
     public StreamWriterToContentHandlerConverter(XMLStreamWriter writer) {
         this.writer = writer;
     }
 
+    /**
+     * Method endDocument
+     *
+     * @throws SAXException
+     */
     public void endDocument() throws SAXException {
-        //do nothing
+
+        // do nothing
     }
 
+    /**
+     * Method startDocument
+     *
+     * @throws SAXException
+     */
     public void startDocument() throws SAXException {
-        //          
+
+        // 
     }
 
-    public void characters(char ch[], int start, int length) throws SAXException {
+    /**
+     * Method characters
+     *
+     * @param ch
+     * @param start
+     * @param length
+     * @throws SAXException
+     */
+    public void characters(char ch[], int start, int length)
+            throws SAXException {
         try {
             writer.writeCharacters(ch, start, length);
         } catch (XMLStreamException e) {
@@ -50,27 +85,74 @@
         }
     }
 
-    public void ignorableWhitespace(char ch[], int start, int length) throws SAXException {
-        //throw new UnsupportedOperationException();
+    /**
+     * Method ignorableWhitespace
+     *
+     * @param ch
+     * @param start
+     * @param length
+     * @throws SAXException
+     */
+    public void ignorableWhitespace(char ch[], int start, int length)
+            throws SAXException {
+
+        // throw new UnsupportedOperationException();
     }
 
+    /**
+     * Method endPrefixMapping
+     *
+     * @param prefix
+     * @throws SAXException
+     */
     public void endPrefixMapping(String prefix) throws SAXException {
-        //throw new UnsupportedOperationException();
+
+        // throw new UnsupportedOperationException();
     }
 
+    /**
+     * Method skippedEntity
+     *
+     * @param name
+     * @throws SAXException
+     */
     public void skippedEntity(String name) throws SAXException {
-        //throw new UnsupportedOperationException();
+
+        // throw new UnsupportedOperationException();
     }
 
+    /**
+     * Method setDocumentLocator
+     *
+     * @param locator
+     */
     public void setDocumentLocator(Locator locator) {
-        //throw new UnsupportedOperationException();
+
+        // throw new UnsupportedOperationException();
     }
 
-    public void processingInstruction(String target, String data) throws SAXException {
+    /**
+     * Method processingInstruction
+     *
+     * @param target
+     * @param data
+     * @throws SAXException
+     */
+    public void processingInstruction(String target, String data)
+            throws SAXException {
+
         // throw new UnsupportedOperationException();
     }
 
-    public void startPrefixMapping(String prefix, String uri) throws SAXException {
+    /**
+     * Method startPrefixMapping
+     *
+     * @param prefix
+     * @param uri
+     * @throws SAXException
+     */
+    public void startPrefixMapping(String prefix, String uri)
+            throws SAXException {
         try {
             writer.writeNamespace(prefix, uri);
             writer.setPrefix(prefix, uri);
@@ -79,7 +161,16 @@
         }
     }
 
-    public void endElement(String namespaceURI, String localName, String qName) throws SAXException {
+    /**
+     * Method endElement
+     *
+     * @param namespaceURI
+     * @param localName
+     * @param qName
+     * @throws SAXException
+     */
+    public void endElement(String namespaceURI, String localName, String qName)
+            throws SAXException {
         try {
             writer.writeEndElement();
         } catch (XMLStreamException e) {
@@ -87,6 +178,12 @@
         }
     }
 
+    /**
+     * Method getPrefix
+     *
+     * @param qName
+     * @return
+     */
     private String getPrefix(String qName) {
         if (qName != null) {
             return qName.substring(0, qName.indexOf(":"));
@@ -94,12 +191,25 @@
         return null;
     }
 
-    public void startElement(String namespaceURI, String localName, String qName, Attributes atts) throws SAXException {
+    /**
+     * Method startElement
+     *
+     * @param namespaceURI
+     * @param localName
+     * @param qName
+     * @param atts
+     * @throws SAXException
+     */
+    public void startElement(
+            String namespaceURI, String localName, String qName, Attributes atts)
+            throws SAXException {
         try {
-            log.info("writing element {" + namespaceURI + '}' + localName + " directly to stream ");
+            log.info("writing element {" + namespaceURI + '}' + localName
+                            + " directly to stream ");
             String prefix = getPrefix(qName);
-            //it is only the prefix we want to learn from the QName! so we can get rid of the 
-            //spliting QName
+
+            // it is only the prefix we want to learn from the QName! so we can get rid of the
+            // spliting QName
             if (prefix == null) {
                 writer.writeStartElement(namespaceURI, localName);
             } else {
@@ -108,8 +218,7 @@
             if (atts != null) {
                 int attCount = atts.getLength();
                 for (int i = 0; i < attCount; i++) {
-                    writer.writeAttribute(atts.getURI(i),
-                            localName,
+                    writer.writeAttribute(atts.getURI(i), localName,
                             atts.getValue(i));
                 }
             }
@@ -117,5 +226,4 @@
             throw new SAXException(e);
         }
     }
-
 }

Modified: webservices/axis/trunk/java/modules/om/src/java/org/apache/axis/om/impl/llom/serialize/StreamingOMSerializer.java
URL: http://svn.apache.org/viewcvs/webservices/axis/trunk/java/modules/om/src/java/org/apache/axis/om/impl/llom/serialize/StreamingOMSerializer.java?view=diff&r1=154467&r2=154468
==============================================================================
--- webservices/axis/trunk/java/modules/om/src/java/org/apache/axis/om/impl/llom/serialize/StreamingOMSerializer.java (original)
+++ webservices/axis/trunk/java/modules/om/src/java/org/apache/axis/om/impl/llom/serialize/StreamingOMSerializer.java Sat Feb 19 19:00:47 2005
@@ -1,19 +1,18 @@
 /*
  * Copyright 2004,2005 The Apache Software Foundation.
- * 
+ *
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.
  * You may obtain a copy of the License at
- * 
+ *
  *      http://www.apache.org/licenses/LICENSE-2.0
- * 
+ *
  * Unless required by applicable law or agreed to in writing, software
  * distributed under the License is distributed on an "AS IS" BASIS,
  * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
- 
 package org.apache.axis.om.impl.llom.serialize;
 
 import org.apache.axis.om.OMException;
@@ -24,26 +23,49 @@
 import javax.xml.stream.XMLStreamReader;
 import javax.xml.stream.XMLStreamWriter;
 
-//import java.util.Stack;
-
+/**
+ * Class StreamingOMSerializer
+ */
 public class StreamingOMSerializer implements XMLStreamConstants, OMSerializer {
 
-    /* The behavior of the serializer is such that it returns when it encounters the
-     starting element for the second time. The depth variable tracks the depth of the
-     serilizer and tells it when to return.
-     Note that it is assumed that this serilization starts on an Element
-    */
+    /*
+     * The behavior of the serializer is such that it returns when it encounters the
+     * starting element for the second time. The depth variable tracks the depth of the
+     * serilizer and tells it when to return.
+     * Note that it is assumed that this serilization starts on an Element
+     */
+
+    /**
+     * Field depth
+     */
     private int depth = 0;
 
-    public void serialize(Object obj, XMLStreamWriter writer) throws XMLStreamException {
+    /**
+     * Method serialize
+     *
+     * @param obj
+     * @param writer
+     * @throws XMLStreamException
+     */
+    public void serialize(Object obj, XMLStreamWriter writer)
+            throws XMLStreamException {
         if (!(obj instanceof XMLStreamReader)) {
-            throw new UnsupportedOperationException("Unsupported input object. Must be of the the type XMLStreamReader");
+            throw new UnsupportedOperationException(
+                    "Unsupported input object. Must be of the the type XMLStreamReader");
         }
         XMLStreamReader node = (XMLStreamReader) obj;
         serializeNode(node, writer);
     }
 
-    protected void serializeNode(XMLStreamReader reader, XMLStreamWriter writer) throws XMLStreamException {
+    /**
+     * Method serializeNode
+     *
+     * @param reader
+     * @param writer
+     * @throws XMLStreamException
+     */
+    protected void serializeNode(XMLStreamReader reader, XMLStreamWriter writer)
+            throws XMLStreamException {
         while (reader.hasNext()) {
             int event = reader.next();
             if (event == START_ELEMENT) {
@@ -64,17 +86,23 @@
                 try {
                     serializeEndElement(writer);
                 } catch (Exception e) {
-                    //this is eaten
+                    //TODO: log exceptions
                 }
             }
-            if (depth == 0) break;
+            if (depth == 0) {
+                break;
+            }
         }
     }
 
     /**
-
+     * @param reader
+     * @param writer
+     * @throws XMLStreamException
      */
-    protected void serializeElement(XMLStreamReader reader, XMLStreamWriter writer) throws XMLStreamException {
+    protected void serializeElement(
+            XMLStreamReader reader, XMLStreamWriter writer)
+            throws XMLStreamException {
         String prefix = reader.getPrefix();
         String nameSpaceName = reader.getNamespaceURI();
         String writer_prefix = writer.getPrefix(nameSpaceName);
@@ -83,70 +111,96 @@
                 writer.writeStartElement(nameSpaceName, reader.getLocalName());
             } else {
                 if (prefix != null) {
-                    writer.writeStartElement(prefix, reader.getLocalName(), nameSpaceName);
+                    writer.writeStartElement(prefix, reader.getLocalName(),
+                            nameSpaceName);
                     writer.writeNamespace(prefix, nameSpaceName);
                     writer.setPrefix(prefix, nameSpaceName);
                 } else {
-                    writer.writeStartElement(nameSpaceName, reader.getLocalName());
+                    writer.writeStartElement(nameSpaceName,
+                            reader.getLocalName());
                     writer.writeDefaultNamespace(nameSpaceName);
                     writer.setDefaultNamespace(nameSpaceName);
                 }
             }
         } else {
-            throw new OMException("Non namespace qualified elements are not allowed");
+            throw new OMException(
+                    "Non namespace qualified elements are not allowed");
         }
 
-        //add attributes
+        // add attributes
         serializeAttributes(reader, writer);
-        //add the namespaces
+
+        // add the namespaces
         int count = reader.getNamespaceCount();
         for (int i = 0; i < count; i++) {
-            serializeNamespace(reader.getNamespacePrefix(i), reader.getNamespaceURI(i), writer);
+            serializeNamespace(reader.getNamespacePrefix(i),
+                    reader.getNamespaceURI(i), writer);
         }
-
-        //namespaceCountStack.push(new Integer(nsPushCount));
-
     }
 
-    protected void serializeEndElement(XMLStreamWriter writer) throws XMLStreamException {
-        //        if (!namespaceCountStack.isEmpty()) {
-        //            Integer removeCount = (Integer) namespaceCountStack.pop();
-        //            int count = removeCount.intValue();
-        //            for (int i = 0; i < count; i++)
-        //                namespacePrefixStack.pop();
-        //        }
+    /**
+     * Method serializeEndElement
+     *
+     * @param writer
+     * @throws XMLStreamException
+     */
+    protected void serializeEndElement(XMLStreamWriter writer)
+            throws XMLStreamException {
         writer.writeEndElement();
-
     }
 
     /**
+     * @param reader
+     * @param writer
+     * @throws XMLStreamException
      */
-    protected void serializeText(XMLStreamReader reader, XMLStreamWriter writer) throws XMLStreamException {
+    protected void serializeText(XMLStreamReader reader, XMLStreamWriter writer)
+            throws XMLStreamException {
         writer.writeCharacters(reader.getText());
     }
 
-    protected void serializeCData(XMLStreamReader reader, XMLStreamWriter writer) throws XMLStreamException {
+    /**
+     * Method serializeCData
+     *
+     * @param reader
+     * @param writer
+     * @throws XMLStreamException
+     */
+    protected void serializeCData(
+            XMLStreamReader reader, XMLStreamWriter writer)
+            throws XMLStreamException {
         writer.writeCData(reader.getText());
     }
 
-    protected void serializeComment(XMLStreamReader reader, XMLStreamWriter writer) throws XMLStreamException {
+    /**
+     * Method serializeComment
+     *
+     * @param reader
+     * @param writer
+     * @throws XMLStreamException
+     */
+    protected void serializeComment(
+            XMLStreamReader reader, XMLStreamWriter writer)
+            throws XMLStreamException {
         writer.writeComment(reader.getText());
     }
 
     /**
+     * @param reader
      * @param writer
      * @throws XMLStreamException
      */
-    protected void serializeAttributes(XMLStreamReader reader, XMLStreamWriter writer) throws XMLStreamException {
+    protected void serializeAttributes(
+            XMLStreamReader reader, XMLStreamWriter writer)
+            throws XMLStreamException {
         int count = reader.getAttributeCount();
         String prefix = null;
         String namespaceName = null;
         for (int i = 0; i < count; i++) {
             prefix = reader.getAttributePrefix(i);
             namespaceName = reader.getAttributeNamespace(i);
-            if (prefix != null && !namespaceName.equals("")) {
-                writer.writeAttribute(prefix,
-                        namespaceName,
+            if ((prefix != null) && !namespaceName.equals("")) {
+                writer.writeAttribute(prefix, namespaceName,
                         reader.getAttributeLocalName(i),
                         reader.getAttributeValue(i));
             } else {
@@ -156,13 +210,21 @@
         }
     }
 
-    private void serializeNamespace(String prefix, String URI, XMLStreamWriter writer) throws XMLStreamException {
+    /**
+     * Method serializeNamespace
+     *
+     * @param prefix
+     * @param URI
+     * @param writer
+     * @throws XMLStreamException
+     */
+    private void serializeNamespace(
+            String prefix, String URI, XMLStreamWriter writer)
+            throws XMLStreamException {
         String prefix1 = writer.getPrefix(URI);
         if (prefix1 == null) {
             writer.writeNamespace(prefix, URI);
             writer.setPrefix(prefix, URI);
         }
-
     }
-
 }

Modified: webservices/axis/trunk/java/modules/om/src/java/org/apache/axis/om/impl/llom/traverse/OMChildrenIterator.java
URL: http://svn.apache.org/viewcvs/webservices/axis/trunk/java/modules/om/src/java/org/apache/axis/om/impl/llom/traverse/OMChildrenIterator.java?view=diff&r1=154467&r2=154468
==============================================================================
--- webservices/axis/trunk/java/modules/om/src/java/org/apache/axis/om/impl/llom/traverse/OMChildrenIterator.java (original)
+++ webservices/axis/trunk/java/modules/om/src/java/org/apache/axis/om/impl/llom/traverse/OMChildrenIterator.java Sat Feb 19 19:00:47 2005
@@ -1,19 +1,18 @@
 /*
  * Copyright 2004,2005 The Apache Software Foundation.
- * 
+ *
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.
  * You may obtain a copy of the License at
- * 
+ *
  *      http://www.apache.org/licenses/LICENSE-2.0
- * 
+ *
  * Unless required by applicable law or agreed to in writing, software
  * distributed under the License is distributed on an "AS IS" BASIS,
  * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
- 
 package org.apache.axis.om.impl.llom.traverse;
 
 import org.apache.axis.om.OMException;
@@ -21,12 +20,35 @@
 
 import java.util.Iterator;
 
+/**
+ * Class OMChildrenIterator
+ */
 public class OMChildrenIterator implements Iterator {
+    /**
+     * Field currentChild
+     */
     protected OMNode currentChild;
+
+    /**
+     * Field lastChild
+     */
     protected OMNode lastChild;
+
+    /**
+     * Field nextCalled
+     */
     protected boolean nextCalled = false;
+
+    /**
+     * Field removeCalled
+     */
     protected boolean removeCalled = false;
 
+    /**
+     * Constructor OMChildrenIterator
+     *
+     * @param currentChild
+     */
     public OMChildrenIterator(OMNode currentChild) {
         this.currentChild = currentChild;
     }
@@ -47,14 +69,15 @@
      */
     public void remove() {
         if (!nextCalled) {
-            throw new IllegalStateException("next method has not yet being called");
+            throw new IllegalStateException(
+                    "next method has not yet being called");
         }
         if (removeCalled) {
             throw new IllegalStateException("remove has already being called");
         }
         removeCalled = true;
 
-        //since this acts on the last child there is no need to mess with the current child
+        // since this acts on the last child there is no need to mess with the current child
         if (lastChild == null) {
             throw new OMException("cannot remove a child at this stage!");
         }
@@ -88,6 +111,5 @@
             return lastChild;
         }
         return null;
-
     }
 }

Modified: webservices/axis/trunk/java/modules/om/src/java/org/apache/axis/om/impl/llom/traverse/OMChildrenQNameIterator.java
URL: http://svn.apache.org/viewcvs/webservices/axis/trunk/java/modules/om/src/java/org/apache/axis/om/impl/llom/traverse/OMChildrenQNameIterator.java?view=diff&r1=154467&r2=154468
==============================================================================
--- webservices/axis/trunk/java/modules/om/src/java/org/apache/axis/om/impl/llom/traverse/OMChildrenQNameIterator.java (original)
+++ webservices/axis/trunk/java/modules/om/src/java/org/apache/axis/om/impl/llom/traverse/OMChildrenQNameIterator.java Sat Feb 19 19:00:47 2005
@@ -1,19 +1,18 @@
 /*
  * Copyright 2004,2005 The Apache Software Foundation.
- * 
+ *
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.
  * You may obtain a copy of the License at
- * 
+ *
  *      http://www.apache.org/licenses/LICENSE-2.0
- * 
+ *
  * Unless required by applicable law or agreed to in writing, software
  * distributed under the License is distributed on an "AS IS" BASIS,
  * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
- 
 package org.apache.axis.om.impl.llom.traverse;
 
 import org.apache.axis.om.OMNode;
@@ -21,12 +20,31 @@
 
 import javax.xml.namespace.QName;
 
+/**
+ * Class OMChildrenQNameIterator
+ */
 public class OMChildrenQNameIterator extends OMChildrenIterator {
+    /**
+     * Field givenQName
+     */
     private QName givenQName;
 
+    /**
+     * Field needToMoveForward
+     */
     private boolean needToMoveForward = true;
+
+    /**
+     * Field isMatchingNodeFound
+     */
     private boolean isMatchingNodeFound = false;
 
+    /**
+     * Constructor OMChildrenQNameIterator
+     *
+     * @param currentChild
+     * @param givenQName
+     */
     public OMChildrenQNameIterator(OMNode currentChild, QName givenQName) {
         super(currentChild);
         this.givenQName = givenQName;
@@ -42,15 +60,20 @@
     public boolean hasNext() {
         while (needToMoveForward) {
             if (currentChild != null) {
+
                 // check the current node for the criteria
-                if ((currentChild instanceof OMNamedNodeImpl) &&
-                        (isQNamesMatch(((OMNamedNodeImpl) currentChild).getQName(), this.givenQName))) {
+                if ((currentChild instanceof OMNamedNodeImpl)
+                        && (isQNamesMatch(
+                                   ((OMNamedNodeImpl) currentChild).getQName(),
+                                   this.givenQName))) {
                     isMatchingNodeFound = true;
                     needToMoveForward = false;
                 } else {
+
                     // get the next named node
                     currentChild = currentChild.getNextSibling();
-                    isMatchingNodeFound = needToMoveForward = !(currentChild == null);
+                    isMatchingNodeFound = needToMoveForward = !(currentChild
+                                                                           == null);
                 }
             } else {
                 needToMoveForward = false;
@@ -67,7 +90,8 @@
      *          iteration has no more elements.
      */
     public Object next() {
-        //reset the flags
+
+        // reset the flags
         needToMoveForward = true;
         isMatchingNodeFound = false;
         nextCalled = true;
@@ -94,16 +118,18 @@
         }
 
         // if the given localname is null, whatever value this.qname has, its a match
-        boolean localNameMatch = qNameToBeMatched.getLocalPart() == null ||
-                qNameToBeMatched.getLocalPart() == "" ||
-                (elementQName != null && elementQName.getLocalPart().equalsIgnoreCase(qNameToBeMatched.getLocalPart()));
-        boolean namespaceURIMatch = qNameToBeMatched.getNamespaceURI() == null ||
-                qNameToBeMatched.getNamespaceURI() == "" ||
-                (elementQName != null && elementQName.getNamespaceURI().equalsIgnoreCase(qNameToBeMatched.getNamespaceURI()));
+        boolean localNameMatch =
+        (qNameToBeMatched.getLocalPart() == null)
+                || (qNameToBeMatched.getLocalPart() == "")
+                || ((elementQName != null)
+                               && elementQName.getLocalPart().equalsIgnoreCase(
+                                       qNameToBeMatched.getLocalPart()));
+        boolean namespaceURIMatch =
+        (qNameToBeMatched.getNamespaceURI() == null)
+                || (qNameToBeMatched.getNamespaceURI() == "")
+                || ((elementQName != null)
+                               && elementQName.getNamespaceURI().equalsIgnoreCase(
+                                       qNameToBeMatched.getNamespaceURI()));
         return localNameMatch && namespaceURIMatch;
-
-
     }
-
-
 }

Modified: webservices/axis/trunk/java/modules/om/src/java/org/apache/axis/om/impl/llom/traverse/OMChildrenWithSpecificAttributeIterator.java
URL: http://svn.apache.org/viewcvs/webservices/axis/trunk/java/modules/om/src/java/org/apache/axis/om/impl/llom/traverse/OMChildrenWithSpecificAttributeIterator.java?view=diff&r1=154467&r2=154468
==============================================================================
--- webservices/axis/trunk/java/modules/om/src/java/org/apache/axis/om/impl/llom/traverse/OMChildrenWithSpecificAttributeIterator.java (original)
+++ webservices/axis/trunk/java/modules/om/src/java/org/apache/axis/om/impl/llom/traverse/OMChildrenWithSpecificAttributeIterator.java Sat Feb 19 19:00:47 2005
@@ -1,19 +1,18 @@
 /*
  * Copyright 2004,2005 The Apache Software Foundation.
- * 
+ *
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.
  * You may obtain a copy of the License at
- * 
+ *
  *      http://www.apache.org/licenses/LICENSE-2.0
- * 
+ *
  * Unless required by applicable law or agreed to in writing, software
  * distributed under the License is distributed on an "AS IS" BASIS,
  * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
- 
 package org.apache.axis.om.impl.llom.traverse;
 
 import org.apache.axis.om.OMAttribute;
@@ -22,31 +21,66 @@
 
 import javax.xml.namespace.QName;
 
-public class OMChildrenWithSpecificAttributeIterator extends OMChildrenIterator {
+/**
+ * Class OMChildrenWithSpecificAttributeIterator
+ */
+public class OMChildrenWithSpecificAttributeIterator
+        extends OMChildrenIterator {
+    /**
+     * Field attributeName
+     */
     private QName attributeName;
+
+    /**
+     * Field attributeValue
+     */
     private String attributeValue;
+
+    /**
+     * Field detach
+     */
     private boolean detach;
 
-    public OMChildrenWithSpecificAttributeIterator(OMNode currentChild, QName attributeName, String attributeValue, boolean detach) {
+    /**
+     * Constructor OMChildrenWithSpecificAttributeIterator
+     *
+     * @param currentChild
+     * @param attributeName
+     * @param attributeValue
+     * @param detach
+     */
+    public OMChildrenWithSpecificAttributeIterator(OMNode currentChild,
+                                                   QName attributeName, String attributeValue, boolean detach) {
         super(currentChild);
         this.attributeName = attributeName;
         this.attributeValue = attributeValue;
         this.detach = detach;
     }
 
+    /**
+     * Method hasNext
+     *
+     * @return
+     */
     public boolean hasNext() {
+
         // First check whether we have a child, using the super class
-        if (currentChild == null)
+        if (currentChild == null) {
             return false;
+        }
         boolean isMatchingNodeFound = false;
         boolean needToMoveForward = true;
 
         // now we have a child to check. If its an OMElement and matches the criteria, then we are done
         while (needToMoveForward) {
+
             // check the current node for the criteria
             if (currentChild instanceof OMElement) {
-                OMAttribute attr = ((OMElement) currentChild).getAttributeWithQName(attributeName);
-                if (attr != null && attr.getValue().equalsIgnoreCase(attributeValue)) {
+                OMAttribute attr =
+                        ((OMElement) currentChild).getAttributeWithQName(
+                        attributeName);
+                if ((attr != null)
+                        && attr.getValue().equalsIgnoreCase(attributeValue)) {
                     isMatchingNodeFound = true;
                     needToMoveForward = false;
                 } else {
@@ -54,21 +88,25 @@
                     needToMoveForward = !(currentChild == null);
                 }
             } else {
+
                 // get the next named node
                 currentChild = currentChild.getNextSibling();
                 needToMoveForward = !(currentChild == null);
             }
-
         }
         return isMatchingNodeFound;
     }
 
+    /**
+     * Method next
+     *
+     * @return
+     */
     public Object next() {
         Object o = super.next();
-        if (o != null && detach) {
+        if ((o != null) && detach) {
             ((OMElement) o).detach();
         }
         return o;
     }
-
 }

Modified: webservices/axis/trunk/java/modules/om/src/test-resources/badsoap/bodyNotQualified.xml
URL: http://svn.apache.org/viewcvs/webservices/axis/trunk/java/modules/om/src/test-resources/badsoap/bodyNotQualified.xml?view=diff&r1=154467&r2=154468
==============================================================================
--- webservices/axis/trunk/java/modules/om/src/test-resources/badsoap/bodyNotQualified.xml (original)
+++ webservices/axis/trunk/java/modules/om/src/test-resources/badsoap/bodyNotQualified.xml Sat Feb 19 19:00:47 2005
@@ -1,9 +1,16 @@
-<soapenv:Envelope xmlns:soapenv="http://schemas.xmlsoap.org/soap/envelope/" xmlns:xsd="http://www.w3.org/2001/XMLSchema" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xmlns:wsa="http://schemas.xmlsoap.org/ws/2004/03/addressing">
+<soapenv:Envelope xmlns:soapenv="http://schemas.xmlsoap.org/soap/envelope/"
+                  xmlns:xsd="http://www.w3.org/2001/XMLSchema"
+                  xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
+                  xmlns:wsa="http://schemas.xmlsoap.org/ws/2004/03/addressing">
     <soapenv:Header>
-        <wsa:MessageID soapenv:mustUnderstand="0">uuid:920C5190-0B8F-11D9-8CED-F22EDEEBF7E5</wsa:MessageID>
-        <wsa:To soapenv:mustUnderstand="0">http://localhost:8081/axis/services/BankPort</wsa:To>
+        <wsa:MessageID soapenv:mustUnderstand="0">
+            uuid:920C5190-0B8F-11D9-8CED-F22EDEEBF7E5</wsa:MessageID>
+        <wsa:To soapenv:mustUnderstand="0">
+            http://localhost:8081/axis/services/BankPort</wsa:To>
         <wsa:From soapenv:mustUnderstand="0">
-            <Address xmlns="http://schemas.xmlsoap.org/ws/2004/03/addressing">http://schemas.xmlsoap.org/ws/2004/03/addressing/role/anonymous</Address>
+            <Address xmlns="http://schemas.xmlsoap.org/ws/2004/03/addressing">
+                http://schemas.xmlsoap.org/ws/2004/03/addressing/role/anonymous
+            </Address>
         </wsa:From>
     </soapenv:Header>
     <soapenv:Body>

Modified: webservices/axis/trunk/java/modules/om/src/test-resources/badsoap/envelopeMissing.xml
URL: http://svn.apache.org/viewcvs/webservices/axis/trunk/java/modules/om/src/test-resources/badsoap/envelopeMissing.xml?view=diff&r1=154467&r2=154468
==============================================================================
--- webservices/axis/trunk/java/modules/om/src/test-resources/badsoap/envelopeMissing.xml (original)
+++ webservices/axis/trunk/java/modules/om/src/test-resources/badsoap/envelopeMissing.xml Sat Feb 19 19:00:47 2005
@@ -1,12 +1,20 @@
-<soapenv:Body xmlns:soapenv="http://schemas.xmlsoap.org/soap/envelope/" xmlns:xsd="http://www.w3.org/2001/XMLSchema" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xmlns:wsa="http://schemas.xmlsoap.org/ws/2004/03/addressing">
+<soapenv:Body xmlns:soapenv="http://schemas.xmlsoap.org/soap/envelope/"
+              xmlns:xsd="http://www.w3.org/2001/XMLSchema"
+              xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
+              xmlns:wsa="http://schemas.xmlsoap.org/ws/2004/03/addressing">
     <soapenv:Header>
-        <wsa:MessageID soapenv:mustUnderstand="0">uuid:920C5190-0B8F-11D9-8CED-F22EDEEBF7E5</wsa:MessageID>
-        <wsa:To soapenv:mustUnderstand="0">http://localhost:8081/axis/services/BankPort</wsa:To>
+        <wsa:MessageID soapenv:mustUnderstand="0">
+            uuid:920C5190-0B8F-11D9-8CED-F22EDEEBF7E5</wsa:MessageID>
+        <wsa:To soapenv:mustUnderstand="0">
+            http://localhost:8081/axis/services/BankPort</wsa:To>
         <wsa:From soapenv:mustUnderstand="0">
-            <Address xmlns="http://schemas.xmlsoap.org/ws/2004/03/addressing">http://schemas.xmlsoap.org/ws/2004/03/addressing/role/anonymous</Address>
+            <Address xmlns="http://schemas.xmlsoap.org/ws/2004/03/addressing">
+                http://schemas.xmlsoap.org/ws/2004/03/addressing/role/anonymous
+            </Address>
         </wsa:From>
     </soapenv:Header>
     <soapenv:Body>
-        <axis2:echoVoid xmlns:axis2="http://ws.apache.org/axis2" ></axis2:echoVoid>
+        <axis2:echoVoid xmlns:axis2="http://ws.apache.org/axis2">
+        </axis2:echoVoid>
     </soapenv:Body>
 </soapenv:Body>

Modified: webservices/axis/trunk/java/modules/om/src/test-resources/badsoap/haederBodyWrongOrder.xml
URL: http://svn.apache.org/viewcvs/webservices/axis/trunk/java/modules/om/src/test-resources/badsoap/haederBodyWrongOrder.xml?view=diff&r1=154467&r2=154468
==============================================================================
--- webservices/axis/trunk/java/modules/om/src/test-resources/badsoap/haederBodyWrongOrder.xml (original)
+++ webservices/axis/trunk/java/modules/om/src/test-resources/badsoap/haederBodyWrongOrder.xml Sat Feb 19 19:00:47 2005
@@ -1,12 +1,20 @@
-<soapenv:Envelope xmlns:soapenv="http://schemas.xmlsoap.org/soap/envelope/" xmlns:xsd="http://www.w3.org/2001/XMLSchema" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xmlns:wsa="http://schemas.xmlsoap.org/ws/2004/03/addressing">
+<soapenv:Envelope xmlns:soapenv="http://schemas.xmlsoap.org/soap/envelope/"
+                  xmlns:xsd="http://www.w3.org/2001/XMLSchema"
+                  xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
+                  xmlns:wsa="http://schemas.xmlsoap.org/ws/2004/03/addressing">
     <soapenv:Body>
-        <axis2:echoVoid xmlns:axis2="http://ws.apache.org/axis2" ></axis2:echoVoid>
+        <axis2:echoVoid xmlns:axis2="http://ws.apache.org/axis2">
+        </axis2:echoVoid>
     </soapenv:Body>
     <soapenv:Header>
-        <wsa:MessageID soapenv:mustUnderstand="0">uuid:920C5190-0B8F-11D9-8CED-F22EDEEBF7E5</wsa:MessageID>
-        <wsa:To soapenv:mustUnderstand="0">http://localhost:8081/axis/services/BankPort</wsa:To>
+        <wsa:MessageID soapenv:mustUnderstand="0">
+            uuid:920C5190-0B8F-11D9-8CED-F22EDEEBF7E5</wsa:MessageID>
+        <wsa:To soapenv:mustUnderstand="0">
+            http://localhost:8081/axis/services/BankPort</wsa:To>
         <wsa:From soapenv:mustUnderstand="0">
-            <Address xmlns="http://schemas.xmlsoap.org/ws/2004/03/addressing">http://schemas.xmlsoap.org/ws/2004/03/addressing/role/anonymous</Address>
+            <Address xmlns="http://schemas.xmlsoap.org/ws/2004/03/addressing">
+                http://schemas.xmlsoap.org/ws/2004/03/addressing/role/anonymous
+            </Address>
         </wsa:From>
     </soapenv:Header>
 </soapenv:Envelope>

Modified: webservices/axis/trunk/java/modules/om/src/test-resources/badsoap/notnamespaceQualified.xml
URL: http://svn.apache.org/viewcvs/webservices/axis/trunk/java/modules/om/src/test-resources/badsoap/notnamespaceQualified.xml?view=diff&r1=154467&r2=154468
==============================================================================
--- webservices/axis/trunk/java/modules/om/src/test-resources/badsoap/notnamespaceQualified.xml (original)
+++ webservices/axis/trunk/java/modules/om/src/test-resources/badsoap/notnamespaceQualified.xml Sat Feb 19 19:00:47 2005
@@ -1,9 +1,12 @@
 <Envelope>
     <Header>
-        <MessageID mustUnderstand="0">uuid:920C5190-0B8F-11D9-8CED-F22EDEEBF7E5</MessageID>
+        <MessageID mustUnderstand="0">uuid:920C5190-0B8F-11D9-8CED-F22EDEEBF7E5
+        </MessageID>
         <To mustUnderstand="0">http://localhost:8081/axis/services/BankPort</To>
         <From mustUnderstand="0">
-            <Address>http://schemas.xmlsoap.org/ws/2004/03/addressing/role/anonymous</Address>
+            <Address>
+                http://schemas.xmlsoap.org/ws/2004/03/addressing/role/anonymous
+            </Address>
         </From>
     </Header>
     <Body>

Modified: webservices/axis/trunk/java/modules/om/src/test-resources/badsoap/twoBodymessage.xml
URL: http://svn.apache.org/viewcvs/webservices/axis/trunk/java/modules/om/src/test-resources/badsoap/twoBodymessage.xml?view=diff&r1=154467&r2=154468
==============================================================================
--- webservices/axis/trunk/java/modules/om/src/test-resources/badsoap/twoBodymessage.xml (original)
+++ webservices/axis/trunk/java/modules/om/src/test-resources/badsoap/twoBodymessage.xml Sat Feb 19 19:00:47 2005
@@ -1,15 +1,24 @@
-<soapenv:Envelope xmlns:soapenv="http://schemas.xmlsoap.org/soap/envelope/" xmlns:xsd="http://www.w3.org/2001/XMLSchema" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xmlns:wsa="http://schemas.xmlsoap.org/ws/2004/03/addressing">
+<soapenv:Envelope xmlns:soapenv="http://schemas.xmlsoap.org/soap/envelope/"
+                  xmlns:xsd="http://www.w3.org/2001/XMLSchema"
+                  xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
+                  xmlns:wsa="http://schemas.xmlsoap.org/ws/2004/03/addressing">
     <soapenv:Header>
-        <wsa:MessageID soapenv:mustUnderstand="0">uuid:920C5190-0B8F-11D9-8CED-F22EDEEBF7E5</wsa:MessageID>
-        <wsa:To soapenv:mustUnderstand="0">http://localhost:8081/axis/services/BankPort</wsa:To>
+        <wsa:MessageID soapenv:mustUnderstand="0">
+            uuid:920C5190-0B8F-11D9-8CED-F22EDEEBF7E5</wsa:MessageID>
+        <wsa:To soapenv:mustUnderstand="0">
+            http://localhost:8081/axis/services/BankPort</wsa:To>
         <wsa:From soapenv:mustUnderstand="0">
-            <Address xmlns="http://schemas.xmlsoap.org/ws/2004/03/addressing">http://schemas.xmlsoap.org/ws/2004/03/addressing/role/anonymous</Address>
+            <Address xmlns="http://schemas.xmlsoap.org/ws/2004/03/addressing">
+                http://schemas.xmlsoap.org/ws/2004/03/addressing/role/anonymous
+            </Address>
         </wsa:From>
     </soapenv:Header>
     <soapenv:Body>
-        <axis2:echoVoid xmlns:axis2="http://ws.apache.org/axis2" ></axis2:echoVoid>
+        <axis2:echoVoid xmlns:axis2="http://ws.apache.org/axis2">
+        </axis2:echoVoid>
     </soapenv:Body>
     <soapenv:Body>
-        <axis2:echoVoid xmlns:axis2="http://ws.apache.org/axis2" ></axis2:echoVoid>
+        <axis2:echoVoid xmlns:axis2="http://ws.apache.org/axis2">
+        </axis2:echoVoid>
     </soapenv:Body>
 </soapenv:Envelope>

Modified: webservices/axis/trunk/java/modules/om/src/test-resources/badsoap/twoheaders.xml
URL: http://svn.apache.org/viewcvs/webservices/axis/trunk/java/modules/om/src/test-resources/badsoap/twoheaders.xml?view=diff&r1=154467&r2=154468
==============================================================================
--- webservices/axis/trunk/java/modules/om/src/test-resources/badsoap/twoheaders.xml (original)
+++ webservices/axis/trunk/java/modules/om/src/test-resources/badsoap/twoheaders.xml Sat Feb 19 19:00:47 2005
@@ -1,16 +1,27 @@
-<soapenv:Envelope xmlns:soapenv="http://schemas.xmlsoap.org/soap/envelope/" xmlns:xsd="http://www.w3.org/2001/XMLSchema" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xmlns:wsa="http://schemas.xmlsoap.org/ws/2004/03/addressing">
+<soapenv:Envelope xmlns:soapenv="http://schemas.xmlsoap.org/soap/envelope/"
+                  xmlns:xsd="http://www.w3.org/2001/XMLSchema"
+                  xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
+                  xmlns:wsa="http://schemas.xmlsoap.org/ws/2004/03/addressing">
     <soapenv:Header>
-        <wsa:MessageID soapenv:mustUnderstand="0">uuid:920C5190-0B8F-11D9-8CED-F22EDEEBF7E5</wsa:MessageID>
-        <wsa:To soapenv:mustUnderstand="0">http://localhost:8081/axis/services/BankPort</wsa:To>
+        <wsa:MessageID soapenv:mustUnderstand="0">
+            uuid:920C5190-0B8F-11D9-8CED-F22EDEEBF7E5</wsa:MessageID>
+        <wsa:To soapenv:mustUnderstand="0">
+            http://localhost:8081/axis/services/BankPort</wsa:To>
         <wsa:From soapenv:mustUnderstand="0">
-            <Address xmlns="http://schemas.xmlsoap.org/ws/2004/03/addressing">http://schemas.xmlsoap.org/ws/2004/03/addressing/role/anonymous</Address>
+            <Address xmlns="http://schemas.xmlsoap.org/ws/2004/03/addressing">
+                http://schemas.xmlsoap.org/ws/2004/03/addressing/role/anonymous
+            </Address>
         </wsa:From>
     </soapenv:Header>
     <soapenv:Header>
-        <wsa:MessageID soapenv:mustUnderstand="0">uuid:920C5190-0B8F-11D9-8CED-F22EDEEBF7E5</wsa:MessageID>
-        <wsa:To soapenv:mustUnderstand="0">http://localhost:8081/axis/services/BankPort</wsa:To>
+        <wsa:MessageID soapenv:mustUnderstand="0">
+            uuid:920C5190-0B8F-11D9-8CED-F22EDEEBF7E5</wsa:MessageID>
+        <wsa:To soapenv:mustUnderstand="0">
+            http://localhost:8081/axis/services/BankPort</wsa:To>
         <wsa:From soapenv:mustUnderstand="0">
-            <Address xmlns="http://schemas.xmlsoap.org/ws/2004/03/addressing">http://schemas.xmlsoap.org/ws/2004/03/addressing/role/anonymous</Address>
+            <Address xmlns="http://schemas.xmlsoap.org/ws/2004/03/addressing">
+                http://schemas.xmlsoap.org/ws/2004/03/addressing/role/anonymous
+            </Address>
         </wsa:From>
     </soapenv:Header>
     <soapenv:Body>

Modified: webservices/axis/trunk/java/modules/om/src/test-resources/badsoap/wrongSoapNs.xml
URL: http://svn.apache.org/viewcvs/webservices/axis/trunk/java/modules/om/src/test-resources/badsoap/wrongSoapNs.xml?view=diff&r1=154467&r2=154468
==============================================================================
--- webservices/axis/trunk/java/modules/om/src/test-resources/badsoap/wrongSoapNs.xml (original)
+++ webservices/axis/trunk/java/modules/om/src/test-resources/badsoap/wrongSoapNs.xml Sat Feb 19 19:00:47 2005
@@ -1,12 +1,20 @@
-<soapenv:Envelope xmlns:soapenv="http://schemas.xmlsoap.org/badsoap/envelope/" xmlns:xsd="http://www.w3.org/2001/XMLSchema" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xmlns:wsa="http://schemas.xmlsoap.org/ws/2004/03/addressing">
+<soapenv:Envelope xmlns:soapenv="http://schemas.xmlsoap.org/badsoap/envelope/"
+                  xmlns:xsd="http://www.w3.org/2001/XMLSchema"
+                  xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
+                  xmlns:wsa="http://schemas.xmlsoap.org/ws/2004/03/addressing">
     <soapenv:Header>
-        <wsa:MessageID soapenv:mustUnderstand="0">uuid:920C5190-0B8F-11D9-8CED-F22EDEEBF7E5</wsa:MessageID>
-        <wsa:To soapenv:mustUnderstand="0">http://localhost:8081/axis/services/BankPort</wsa:To>
+        <wsa:MessageID soapenv:mustUnderstand="0">
+            uuid:920C5190-0B8F-11D9-8CED-F22EDEEBF7E5</wsa:MessageID>
+        <wsa:To soapenv:mustUnderstand="0">
+            http://localhost:8081/axis/services/BankPort</wsa:To>
         <wsa:From soapenv:mustUnderstand="0">
-            <Address xmlns="http://schemas.xmlsoap.org/ws/2004/03/addressing">http://schemas.xmlsoap.org/ws/2004/03/addressing/role/anonymous</Address>
+            <Address xmlns="http://schemas.xmlsoap.org/ws/2004/03/addressing">
+                http://schemas.xmlsoap.org/ws/2004/03/addressing/role/anonymous
+            </Address>
         </wsa:From>
     </soapenv:Header>
     <soapenv:Body>
-        <axis2:echoVoid xmlns:axis2="http://ws.apache.org/axis2" ></axis2:echoVoid>
+        <axis2:echoVoid xmlns:axis2="http://ws.apache.org/axis2">
+        </axis2:echoVoid>
     </soapenv:Body>
 </soapenv:Envelope>

Modified: webservices/axis/trunk/java/modules/om/src/test-resources/non_soap.xml
URL: http://svn.apache.org/viewcvs/webservices/axis/trunk/java/modules/om/src/test-resources/non_soap.xml?view=diff&r1=154467&r2=154468
==============================================================================
--- webservices/axis/trunk/java/modules/om/src/test-resources/non_soap.xml (original)
+++ webservices/axis/trunk/java/modules/om/src/test-resources/non_soap.xml Sat Feb 19 19:00:47 2005
@@ -1,4 +1,5 @@
-<ns1:Root xmlns:ns1="http://www.apache.org" xmlns:ns2="http://www.opensource.lk" >
+<ns1:Root xmlns:ns1="http://www.apache.org"
+          xmlns:ns2="http://www.opensource.lk">
     <ns2:developers xmlns:ns3="http://www.whatever.com">
         <ns3:developer>
             <name>Davanum Srinivas</name>

Modified: webservices/axis/trunk/java/modules/om/src/test-resources/soap/emtyBodymessage.xml
URL: http://svn.apache.org/viewcvs/webservices/axis/trunk/java/modules/om/src/test-resources/soap/emtyBodymessage.xml?view=diff&r1=154467&r2=154468
==============================================================================
--- webservices/axis/trunk/java/modules/om/src/test-resources/soap/emtyBodymessage.xml (original)
+++ webservices/axis/trunk/java/modules/om/src/test-resources/soap/emtyBodymessage.xml Sat Feb 19 19:00:47 2005
@@ -1,9 +1,16 @@
-<soapenv:Envelope xmlns:soapenv="http://schemas.xmlsoap.org/soap/envelope/" xmlns:xsd="http://www.w3.org/2001/XMLSchema" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xmlns:wsa="http://schemas.xmlsoap.org/ws/2004/03/addressing">
+<soapenv:Envelope xmlns:soapenv="http://schemas.xmlsoap.org/soap/envelope/"
+                  xmlns:xsd="http://www.w3.org/2001/XMLSchema"
+                  xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
+                  xmlns:wsa="http://schemas.xmlsoap.org/ws/2004/03/addressing">
     <soapenv:Header>
-        <wsa:MessageID soapenv:mustUnderstand="0">uuid:920C5190-0B8F-11D9-8CED-F22EDEEBF7E5</wsa:MessageID>
-        <wsa:To soapenv:mustUnderstand="0">http://localhost:8081/axis/services/BankPort</wsa:To>
+        <wsa:MessageID soapenv:mustUnderstand="0">
+            uuid:920C5190-0B8F-11D9-8CED-F22EDEEBF7E5</wsa:MessageID>
+        <wsa:To soapenv:mustUnderstand="0">
+            http://localhost:8081/axis/services/BankPort</wsa:To>
         <wsa:From soapenv:mustUnderstand="0">
-            <Address xmlns="http://schemas.xmlsoap.org/ws/2004/03/addressing">http://schemas.xmlsoap.org/ws/2004/03/addressing/role/anonymous</Address>
+            <Address xmlns="http://schemas.xmlsoap.org/ws/2004/03/addressing">
+                http://schemas.xmlsoap.org/ws/2004/03/addressing/role/anonymous
+            </Address>
         </wsa:From>
     </soapenv:Header>
     <soapenv:Body>

Modified: webservices/axis/trunk/java/modules/om/src/test-resources/soap/minimalMessage.xml
URL: http://svn.apache.org/viewcvs/webservices/axis/trunk/java/modules/om/src/test-resources/soap/minimalMessage.xml?view=diff&r1=154467&r2=154468
==============================================================================
--- webservices/axis/trunk/java/modules/om/src/test-resources/soap/minimalMessage.xml (original)
+++ webservices/axis/trunk/java/modules/om/src/test-resources/soap/minimalMessage.xml Sat Feb 19 19:00:47 2005
@@ -1,4 +1,4 @@
 <?xml version='1.0' ?>
-<env:Envelope xmlns:env="http://schemas.xmlsoap.org/soap/envelope/"> 
-	<env:Body/>
+<env:Envelope xmlns:env="http://schemas.xmlsoap.org/soap/envelope/">
+    <env:Body/>
 </env:Envelope>