You are viewing a plain text version of this content. The canonical link for it is here.
Posted to java-commits@axis.apache.org by bi...@apache.org on 2020/04/14 20:02:12 UTC

[axis-axis2-java-core] branch 1_5 created (now 93c490c)

This is an automated email from the ASF dual-hosted git repository.

billblough pushed a change to branch 1_5
in repository https://gitbox.apache.org/repos/asf/axis-axis2-java-core.git.


      at 93c490c   Merged 1359504 to 1.5 branch.

This branch includes the following new commits:

     new 0a34148  [maven-release-plugin] prepare for next development iteration
     new 3309b80  Merged r1037135 and r1037218 to the 1.5 branch to fix the ConcurrentModificationException that sometimes causes the Hudson build to fail.
     new 0c5cb2a  Merged r1174618 to the 1.5 branch.
     new 1147e97  Merged r1150055 to the 1.5 branch to ensure compatibility with Axiom 1.2.13.
     new bff447b  Merged r1147485, r1149224, r1149491 and r1149578 to the 1.5 branch to ensure compatibility with Axiom 1.2.13.
     new 0847de1  Switched Axiom to 1.2.13-SNAPSHOT.
     new e929313  Backported r795789 and part of r1042244 to the 1.5 branch to reduce the coupling to Axiom internals. This should solve AXIS2-4363 and AXIS2-4387.
     new b29d549  Merged r1185504 to the 1.5  branch.
     new 7ed1570  Merged r1190469 to the 1.5 branch.
     new 7be8bc9  AXIS2-5173: Merged r835745 to the 1.5 branch.
     new 8f3d0ce  Merged r922830 to the 1.5 branch to set up svn:ignore for the axis2-kernel module.
     new 783eae3  Merged r922828 to the 1.5 branch to be able to import axis2-kernel into Eclipse.
     new 6c7a3dc  Merged r1201957 to the 1.5 branch.
     new 0ce4c8f  Merged r1201467 to the 1.5 branch to make sure that the build succeeds with Axiom 1.2.13-SNAPSHOT.
     new 15d9a12  Merged r1220630 to the 1.5 branch for use in the Sandesha2 build.
     new c480fe3  Merged r1231465 to the 1.5 branch.
     new fe0e2ae  Merged r1231470 to the 1.5 branch.
     new 950a1d8  Merged r1242249 to the 1.5 branch.
     new 6de6035  Merged r1296062 to the 1.5 branch.
     new a5455e4  Merged r1297744 to the 1.5 branch.
     new fde252c  Merged r1297765 to the 1.5 branch.
     new 04a183e  Merged r1298550 to the 1.5 branch.
     new f163826  Merged r1173869 and r1299356 to the 1.5 branch.
     new d113d79  Merged r1299392 to the 1.5 branch to avoid hanging builds.
     new a41bfca  Merged r1300358 to the 1.5 branch.
     new 27919d3  Switched the Axis2 1.5 branch to Axiom 1.2.13.
     new 9997c20  Merged r1326968 to the 1.5 branch.
     new 79d7495  Merged r1331616 to the 1.5 branch.
     new 09be564  Mark r1341780 merged to 1.5 and applied given patch.
     new bbdf4b7  Merged  r1332587  to the 1.5 branch.
     new 64bf4ca  Merged  r1341805  to the 1.5 branch.
     new 0b99cd8  AXIS2-5345 - Merged r1351218 to 1.5  branch.
     new 18e5409  AXIS2-5349 - Merged r1352413 to 1.5 branch.
     new 8fa0853  AXIS2-5348 - Merged r1352413 to 1.5 branch.
     new afa04b2  AXIS2-5355 - Merged r1356080 to 1.5 branch.
     new 3a1d4bd  AXIS2-5360 - Merged r1358508 to 1.5 branch.
     new 16c5219   Merged r1359499 to 1.5 branch.
     new 93c490c   Merged 1359504 to 1.5 branch.

The 38 revisions listed above as "new" are entirely new to this
repository and will be described in separate emails.  The revisions
listed as "add" were already present in the repository and have only
been added to this reference.



[axis-axis2-java-core] 31/38: Merged r1341805 to the 1.5 branch.

Posted by bi...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

billblough pushed a commit to branch 1_5
in repository https://gitbox.apache.org/repos/asf/axis-axis2-java-core.git

commit 64bf4ca51abc312ef3adb8e600cd926dcafe07af
Author: Sagara Gunathunga <sa...@apache.org>
AuthorDate: Wed May 23 09:30:17 2012 +0000

    Merged  r1341805  to the 1.5 branch.
---
 .../adb-codegen/src/org/apache/axis2/schema/typemap/JavaTypeMap.java   | 3 +++
 1 file changed, 3 insertions(+)

diff --git a/modules/adb-codegen/src/org/apache/axis2/schema/typemap/JavaTypeMap.java b/modules/adb-codegen/src/org/apache/axis2/schema/typemap/JavaTypeMap.java
index fe0a337..30ed9d1 100644
--- a/modules/adb-codegen/src/org/apache/axis2/schema/typemap/JavaTypeMap.java
+++ b/modules/adb-codegen/src/org/apache/axis2/schema/typemap/JavaTypeMap.java
@@ -91,6 +91,9 @@ public class JavaTypeMap implements TypeMap {
         addTypemapping(SchemaConstants.XSD_ANYTYPE,
                 Object.class.getName());
 
+        addTypemapping(SchemaConstants.XSD_ANYSIMPLETYPE,
+                Object.class.getName());
+
         //Qname maps to  jax rpc QName class
         addTypemapping(SchemaConstants.XSD_QNAME,
                 javax.xml.namespace.QName.class.getName());


[axis-axis2-java-core] 15/38: Merged r1220630 to the 1.5 branch for use in the Sandesha2 build.

Posted by bi...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

billblough pushed a commit to branch 1_5
in repository https://gitbox.apache.org/repos/asf/axis-axis2-java-core.git

commit 15d9a12627204f122010d6b43315529cca52831c
Author: Andreas Veithen <ve...@apache.org>
AuthorDate: Wed Dec 21 10:03:09 2011 +0000

    Merged r1220630 to the 1.5 branch for use in the Sandesha2 build.
---
 .../org/apache/axis2/testutils/PortAllocator.java  | 42 ++++++++++++++++++++++
 .../http/server/DefaultConnectionListener.java     | 23 ++++++++++--
 .../transport/http/server/SimpleHttpServer.java    | 11 ++++--
 3 files changed, 71 insertions(+), 5 deletions(-)

diff --git a/modules/testutils/src/main/java/org/apache/axis2/testutils/PortAllocator.java b/modules/testutils/src/main/java/org/apache/axis2/testutils/PortAllocator.java
new file mode 100644
index 0000000..d8fdf8e
--- /dev/null
+++ b/modules/testutils/src/main/java/org/apache/axis2/testutils/PortAllocator.java
@@ -0,0 +1,42 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements. See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership. The ASF licenses this file
+ * to you 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.axis2.testutils;
+
+import java.io.IOException;
+import java.net.ServerSocket;
+
+public final class PortAllocator {
+    private PortAllocator() {}
+    
+    /**
+     * Allocate a TCP port.
+     * 
+     * @return the allocated port
+     */
+    public static int allocatePort() {
+        try {
+            ServerSocket ss = new ServerSocket(0);
+            int port = ss.getLocalPort();
+            ss.close();
+            return port;
+        } catch (IOException ex) {
+            throw new Error("Unable to allocate TCP port", ex);
+        }
+    }
+}
diff --git a/modules/transport/http/src/org/apache/axis2/transport/http/server/DefaultConnectionListener.java b/modules/transport/http/src/org/apache/axis2/transport/http/server/DefaultConnectionListener.java
index d931c8b..2c39991 100644
--- a/modules/transport/http/src/org/apache/axis2/transport/http/server/DefaultConnectionListener.java
+++ b/modules/transport/http/src/org/apache/axis2/transport/http/server/DefaultConnectionListener.java
@@ -72,8 +72,11 @@ public class DefaultConnectionListener implements IOProcessor {
                         if (LOG.isInfoEnabled()) {
                             LOG.info("Listening on port " + port);
                         }
-                        serversocket = new ServerSocket(port);
-                        serversocket.setReuseAddress(true);
+                        synchronized (this) {
+                            serversocket = new ServerSocket(port);
+                            serversocket.setReuseAddress(true);
+                            notifyAll();
+                        }
                     }
                     LOG.debug("Waiting for incoming HTTP connection");
                     Socket socket = this.serversocket.accept();
@@ -96,12 +99,26 @@ public class DefaultConnectionListener implements IOProcessor {
             }
         } finally {
             destroy();
+            synchronized (this) {
+                notifyAll();
+            }
         }
     }
 
-    public void close() throws IOException {
+    public synchronized void awaitSocketOpen() throws InterruptedException {
+        while (serversocket == null) {
+            wait();
+        }
+    }
+    
+    public synchronized int getPort() {
+        return serversocket.getLocalPort();
+    }
+    
+    public synchronized void close() throws IOException {
         if (this.serversocket != null) {
             this.serversocket.close();
+            this.serversocket = null;
         }
     }
 
diff --git a/modules/transport/http/src/org/apache/axis2/transport/http/server/SimpleHttpServer.java b/modules/transport/http/src/org/apache/axis2/transport/http/server/SimpleHttpServer.java
index b2d6a97..7debb56 100644
--- a/modules/transport/http/src/org/apache/axis2/transport/http/server/SimpleHttpServer.java
+++ b/modules/transport/http/src/org/apache/axis2/transport/http/server/SimpleHttpServer.java
@@ -38,7 +38,7 @@ public class SimpleHttpServer {
     private static final int SHUTDOWN_GRACE_PERIOD = 3000; // ms
 
     private HttpFactory httpFactory;
-    private final int port;
+    private int port;
     private final HttpParams params;
     private final WorkerFactory workerFactory;
 
@@ -96,7 +96,14 @@ public class SimpleHttpServer {
     }
 
     public void start() {
-        this.listenerExecutor.execute(this.listener);
+        DefaultConnectionListener listener = (DefaultConnectionListener)this.listener;
+        this.listenerExecutor.execute(listener);
+        try {
+            listener.awaitSocketOpen();
+            port = listener.getPort();
+        } catch (InterruptedException ex) {
+            Thread.currentThread().interrupt();
+        }
     }
 
     public boolean isRunning() {


[axis-axis2-java-core] 08/38: Merged r1185504 to the 1.5 branch.

Posted by bi...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

billblough pushed a commit to branch 1_5
in repository https://gitbox.apache.org/repos/asf/axis-axis2-java-core.git

commit b29d549a9566470d3d5c805060ca6617466133a7
Author: Sagara Gunathunga <sa...@apache.org>
AuthorDate: Tue Oct 18 07:23:43 2011 +0000

    Merged r1185504 to the 1.5  branch.
---
 .../axis2/databinding/utils/ConverterUtil.java     | 34 ++++++++++++++--------
 .../axis2/databinding/utils/ConverterUtilTest.java | 15 ++++++++++
 2 files changed, 37 insertions(+), 12 deletions(-)

diff --git a/modules/adb/src/org/apache/axis2/databinding/utils/ConverterUtil.java b/modules/adb/src/org/apache/axis2/databinding/utils/ConverterUtil.java
index ad98668..9968867 100644
--- a/modules/adb/src/org/apache/axis2/databinding/utils/ConverterUtil.java
+++ b/modules/adb/src/org/apache/axis2/databinding/utils/ConverterUtil.java
@@ -73,6 +73,7 @@ import javax.xml.stream.XMLStreamReader;
 import javax.xml.stream.XMLStreamWriter;
 import java.io.ByteArrayInputStream;
 import java.io.InputStream;
+import java.io.IOException;
 import java.lang.reflect.Array;
 import java.lang.reflect.Constructor;
 import java.lang.reflect.InvocationTargetException;
@@ -1316,18 +1317,27 @@ public class ConverterUtil {
      *
      * @return string
      */
-    public static String getStringFromDatahandler(DataHandler dataHandler) {
-        try {
-            InputStream inStream;
-            if (dataHandler == null) {
-                return "";
-            }
-            inStream = dataHandler.getDataSource().getInputStream();
-            byte[] data = IOUtils.getStreamAsByteArray(inStream);
-            return Base64.encode(data);
-        } catch (Exception e) {
-            throw new RuntimeException(e);
-        }
+	public static String getStringFromDatahandler(DataHandler dataHandler) {
+		InputStream inStream = null;
+		try {
+			if (dataHandler == null) {
+				return "";
+			}
+			inStream = dataHandler.getDataSource().getInputStream();
+			byte[] data = IOUtils.getStreamAsByteArray(inStream);
+			return Base64.encode(data);
+		} catch (Exception e) {
+			throw new RuntimeException(e);
+
+		} finally {
+			try {
+				if (inStream != null)
+					inStream.close();
+			} catch (IOException e) {
+				e.printStackTrace();
+			}
+
+		}
     }
 
     /**
diff --git a/modules/adb/test/org/apache/axis2/databinding/utils/ConverterUtilTest.java b/modules/adb/test/org/apache/axis2/databinding/utils/ConverterUtilTest.java
index 63d47ba..fc5ef08 100644
--- a/modules/adb/test/org/apache/axis2/databinding/utils/ConverterUtilTest.java
+++ b/modules/adb/test/org/apache/axis2/databinding/utils/ConverterUtilTest.java
@@ -29,6 +29,12 @@ import java.util.Date;
 import java.util.List;
 import java.util.TimeZone;
 
+import javax.activation.DataHandler;
+import javax.activation.DataSource;
+
+import org.apache.axiom.attachments.ByteArrayDataSource;
+import org.apache.axiom.om.util.Base64;
+
 public class ConverterUtilTest extends TestCase {
 
     /** Test conversion of Big Integer */
@@ -165,4 +171,13 @@ public class ConverterUtilTest extends TestCase {
         
     }
 
+            
+	public void testConvertToStringFromDataHandler() {
+		String inStr = "Sample Data";
+		DataSource ds = new ByteArrayDataSource(inStr.getBytes());
+		DataHandler dh = new DataHandler(ds);
+		String rawOutStr = ConverterUtil.convertToString(dh);
+		String outStr = new String(Base64.decode(rawOutStr));
+		assertEquals("Not expected content", inStr, outStr);
+	}
 }


[axis-axis2-java-core] 28/38: Merged r1331616 to the 1.5 branch.

Posted by bi...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

billblough pushed a commit to branch 1_5
in repository https://gitbox.apache.org/repos/asf/axis-axis2-java-core.git

commit 79d7495856c84740c46d53231dd750b669012426
Author: Andreas Veithen <ve...@apache.org>
AuthorDate: Sun Apr 29 20:13:24 2012 +0000

    Merged r1331616 to the 1.5 branch.
---
 .../kernel/src/org/apache/axis2/util/MessageContextBuilder.java   | 8 ++++----
 1 file changed, 4 insertions(+), 4 deletions(-)

diff --git a/modules/kernel/src/org/apache/axis2/util/MessageContextBuilder.java b/modules/kernel/src/org/apache/axis2/util/MessageContextBuilder.java
index d62fb00..5faa6b3 100644
--- a/modules/kernel/src/org/apache/axis2/util/MessageContextBuilder.java
+++ b/modules/kernel/src/org/apache/axis2/util/MessageContextBuilder.java
@@ -482,13 +482,13 @@ public class MessageContextBuilder {
                     if (faultCodeQName.getLocalPart().indexOf(":") == -1) {
                         String prefix = faultCodeQName.getPrefix();
                         String uri = faultCodeQName.getNamespaceURI();
-                        // Get the specified prefix and uri
-                        prefix = prefix == null ? "" : prefix;
+                        // Get the specified uri
                         uri = uri == null || "" .equals(uri) ?
                                 fault.getNamespace().getNamespaceURI() : uri;
                         // Make sure the prefix and uri are declared on the fault, and 
-                        // get the resulting prefix.
-                        prefix = fault.declareNamespace(uri, prefix).getPrefix();
+                        // get the resulting prefix. If no prefix is defined, let declareNamespace
+                        // generate one.
+                        prefix = fault.declareNamespace(uri, prefix.length() == 0 ? null : prefix).getPrefix();
                         soapFaultCode = prefix + ":" + faultCodeQName.getLocalPart();
                     } else {
                         soapFaultCode = faultCodeQName.getLocalPart();


[axis-axis2-java-core] 20/38: Merged r1297744 to the 1.5 branch.

Posted by bi...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

billblough pushed a commit to branch 1_5
in repository https://gitbox.apache.org/repos/asf/axis-axis2-java-core.git

commit a5455e4818ac4120363a9d3c0f8e4ef4478ee391
Author: Andreas Veithen <ve...@apache.org>
AuthorDate: Tue Mar 6 22:17:28 2012 +0000

    Merged r1297744 to the 1.5 branch.
---
 modules/saaj/src/org/apache/axis2/saaj/NodeImplEx.java | 5 +++++
 1 file changed, 5 insertions(+)

diff --git a/modules/saaj/src/org/apache/axis2/saaj/NodeImplEx.java b/modules/saaj/src/org/apache/axis2/saaj/NodeImplEx.java
index 469d3c0..04f0f3b 100644
--- a/modules/saaj/src/org/apache/axis2/saaj/NodeImplEx.java
+++ b/modules/saaj/src/org/apache/axis2/saaj/NodeImplEx.java
@@ -293,4 +293,9 @@ public abstract class NodeImplEx extends NodeImpl implements Node {
             return saajSOAPElement;
         }
     }
+    
+    // TODO: the existence of this method probably indicates a problem in TextImplEx
+    public org.w3c.dom.Node getParentNode() {
+        return null;
+    }
 }


[axis-axis2-java-core] 05/38: Merged r1147485, r1149224, r1149491 and r1149578 to the 1.5 branch to ensure compatibility with Axiom 1.2.13.

Posted by bi...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

billblough pushed a commit to branch 1_5
in repository https://gitbox.apache.org/repos/asf/axis-axis2-java-core.git

commit bff447b0a7f756c29bced965eb98f8af0fafe0bd
Author: Andreas Veithen <ve...@apache.org>
AuthorDate: Fri Sep 30 19:41:44 2011 +0000

    Merged r1147485, r1149224, r1149491 and r1149578 to the 1.5 branch to ensure compatibility with Axiom 1.2.13.
---
 modules/saaj/src/org/apache/axis2/saaj/SOAPBodyImpl.java    | 10 ++++++----
 modules/saaj/src/org/apache/axis2/saaj/SOAPElementImpl.java | 12 +++++++++---
 modules/saaj/src/org/apache/axis2/saaj/SOAPFactoryImpl.java |  7 +++++--
 .../saaj/test/org/apache/axis2/saaj/SOAPElementTest.java    | 13 +++++++++++++
 4 files changed, 33 insertions(+), 9 deletions(-)

diff --git a/modules/saaj/src/org/apache/axis2/saaj/SOAPBodyImpl.java b/modules/saaj/src/org/apache/axis2/saaj/SOAPBodyImpl.java
index d6ed3d0..e9535b3 100644
--- a/modules/saaj/src/org/apache/axis2/saaj/SOAPBodyImpl.java
+++ b/modules/saaj/src/org/apache/axis2/saaj/SOAPBodyImpl.java
@@ -164,11 +164,14 @@ public class SOAPBodyImpl extends SOAPElementImpl implements SOAPBody {
         if (omSOAPBody.hasFault()) {
             throw new SOAPException("A SOAPFault has been already added to this SOAPBody");
         }
+        if (prefix == null) {
+            prefix = "";
+        }
         SOAPBodyElementImpl childEle;
         if (uri == null || "".equals(uri)) {
             childEle = new SOAPBodyElementImpl(
                     (ElementImpl)getOwnerDocument().createElement(localName));
-        } else if (prefix == null || "".equals(prefix)) {
+        } else if (prefix.length() == 0) {
             childEle = new SOAPBodyElementImpl(
                 (ElementImpl)getOwnerDocument().createElementNS(uri,
                                                                 localName));
@@ -178,7 +181,7 @@ public class SOAPBodyImpl extends SOAPElementImpl implements SOAPBody {
                                                                     prefix + ":" + localName));
         }
         childEle.element.setUserData(SAAJ_NODE, childEle, null);
-        childEle.element.setNamespace(childEle.element.declareNamespace(uri, prefix));
+        childEle.element.setNamespace(getOMFactory().createOMNamespace(uri, prefix));
         element.appendChild(childEle.element);
         ((NodeImpl)childEle.element.getParentNode()).setUserData(SAAJ_NODE, this, null);
         isBodyElementAdded = true;
@@ -546,8 +549,7 @@ public class SOAPBodyImpl extends SOAPElementImpl implements SOAPBody {
                                                                             qname.getLocalPart()));
         }
         childEle.element.setUserData(SAAJ_NODE, childEle, null);
-        childEle.element.setNamespace(childEle.element.declareNamespace(
-                qname.getNamespaceURI(), qname.getPrefix()));
+        childEle.element.setNamespace(getOMFactory().createOMNamespace(qname.getNamespaceURI(), qname.getPrefix()));
 
         element.appendChild(childEle.element);
         ((NodeImpl)childEle.element.getParentNode()).setUserData(SAAJ_NODE, this, null);
diff --git a/modules/saaj/src/org/apache/axis2/saaj/SOAPElementImpl.java b/modules/saaj/src/org/apache/axis2/saaj/SOAPElementImpl.java
index 065b980..991b8c8 100644
--- a/modules/saaj/src/org/apache/axis2/saaj/SOAPElementImpl.java
+++ b/modules/saaj/src/org/apache/axis2/saaj/SOAPElementImpl.java
@@ -175,7 +175,7 @@ public class SOAPElementImpl extends NodeImplEx implements SOAPElement {
     */
     public SOAPElement addChildElement(String localName, String prefix, String uri)
             throws SOAPException {
-        OMNamespace omNamespace = element.declareNamespace(uri, prefix);
+        OMNamespace omNamespace = prefix == null || prefix.length() == 0 ? element.declareDefaultNamespace(uri) : element.declareNamespace(uri, prefix);
         return addChildElement(localName, omNamespace.getPrefix());
     }
 
@@ -194,7 +194,9 @@ public class SOAPElementImpl extends NodeImplEx implements SOAPElement {
                         createElementNS(namespaceURI, prefix + ":" + localName));
 
         childEle.element.setUserData(SAAJ_NODE, childEle, null);
-        childEle.element.setNamespace(childEle.element.declareNamespace(namespaceURI, prefix));
+        childEle.element.setNamespace(prefix == null || prefix.length() == 0
+                ? childEle.element.declareDefaultNamespace(namespaceURI)
+                : childEle.element.declareNamespace(namespaceURI, prefix));
         element.appendChild(childEle.element);
         ((NodeImpl)childEle.element.getParentNode()).setUserData(SAAJ_NODE, this, null);
         childEle.setParentElement(this);
@@ -218,7 +220,11 @@ public class SOAPElementImpl extends NodeImplEx implements SOAPElement {
       * @see javax.xml.soap.SOAPElement#addNamespaceDeclaration(java.lang.String, java.lang.String)
       */
     public SOAPElement addNamespaceDeclaration(String prefix, String uri) throws SOAPException {
-        element.declareNamespace(uri, prefix);
+        if (prefix == null || prefix.length() == 0) {
+            element.declareDefaultNamespace(uri);
+        } else {
+            element.declareNamespace(uri, prefix);
+        }
         return this;
     }
 
diff --git a/modules/saaj/src/org/apache/axis2/saaj/SOAPFactoryImpl.java b/modules/saaj/src/org/apache/axis2/saaj/SOAPFactoryImpl.java
index cf8af62..db2a9be 100644
--- a/modules/saaj/src/org/apache/axis2/saaj/SOAPFactoryImpl.java
+++ b/modules/saaj/src/org/apache/axis2/saaj/SOAPFactoryImpl.java
@@ -226,8 +226,11 @@ public class SOAPFactoryImpl extends SOAPFactory {
         } else {
             omdomFactory = (OMDOMFactory)DOOMAbstractFactory.getSOAP11Factory();
         }
-        OMNamespace ns = omdomFactory.createOMNamespace(element.getNamespaceURI()
-                , element.getPrefix());
+        String prefix = element.getPrefix();
+        if (prefix == null) {
+            prefix = "";
+        }
+        OMNamespace ns = omdomFactory.createOMNamespace(element.getNamespaceURI(), prefix);
         OMElement omElement = omdomFactory.createOMElement(element.getLocalName(), ns);
         return new SOAPElementImpl((ElementImpl)omElement);
     }
diff --git a/modules/saaj/test/org/apache/axis2/saaj/SOAPElementTest.java b/modules/saaj/test/org/apache/axis2/saaj/SOAPElementTest.java
index 35abf88..c386527 100644
--- a/modules/saaj/test/org/apache/axis2/saaj/SOAPElementTest.java
+++ b/modules/saaj/test/org/apache/axis2/saaj/SOAPElementTest.java
@@ -23,9 +23,11 @@ import junit.framework.Assert;
 import org.junit.Before;
 import org.junit.Test;
 import org.junit.runner.RunWith;
+import org.w3c.dom.Attr;
 import org.w3c.dom.Document;
 import org.w3c.dom.Element;
 
+import javax.xml.XMLConstants;
 import javax.xml.namespace.QName;
 import javax.xml.soap.MessageFactory;
 import javax.xml.soap.Name;
@@ -381,6 +383,17 @@ public class SOAPElementTest extends Assert {
     }
 
     @Validated @Test
+    public void testAddNamespaceDeclarationDefaultNamespace() throws SOAPException {
+        SOAPMessage msg = MessageFactory.newInstance().createMessage();
+        SOAPEnvelope envelope = msg.getSOAPPart().getEnvelope();
+        SOAPBody body = envelope.getBody();
+        SOAPElement element = body.addChildElement("test", "p", "urn:test");
+        element.addNamespaceDeclaration("", "urn:ns");
+        Attr attr = (Attr)element.getAttributes().getNamedItemNS(XMLConstants.XMLNS_ATTRIBUTE_NS_URI, "xmlns");
+        assertEquals("urn:ns", attr.getValue());
+    }
+    
+    @Validated @Test
     public void testRemoveNamespaceDeclaration() throws Exception {
         String prefix = "myPrefix";
         String uri = "myURI";


[axis-axis2-java-core] 29/38: Mark r1341780 merged to 1.5 and applied given patch.

Posted by bi...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

billblough pushed a commit to branch 1_5
in repository https://gitbox.apache.org/repos/asf/axis-axis2-java-core.git

commit 09be5641e4deaddc9d29b4ff8f16e27a9b7cc4fc
Author: Sagara Gunathunga <sa...@apache.org>
AuthorDate: Wed May 23 08:48:50 2012 +0000

    Mark r1341780 merged to 1.5 and applied given patch.
---
 .../axis2/databinding/utils/ConverterUtil.java     |  18 +-
 .../axis2/databinding/utils/ConverterUtilTest.java | 347 ++++++++++++++++++---
 2 files changed, 317 insertions(+), 48 deletions(-)

diff --git a/modules/adb/src/org/apache/axis2/databinding/utils/ConverterUtil.java b/modules/adb/src/org/apache/axis2/databinding/utils/ConverterUtil.java
index 9968867..6d845f3 100644
--- a/modules/adb/src/org/apache/axis2/databinding/utils/ConverterUtil.java
+++ b/modules/adb/src/org/apache/axis2/databinding/utils/ConverterUtil.java
@@ -882,6 +882,7 @@ public class ConverterUtil {
         int second = 0;
         long miliSecond = 0;
         int timeZoneOffSet = TimeZone.getDefault().getRawOffset();
+        boolean haveTimeZone;
 
 
         if ((source != null) && (source.length() >= 19)) {
@@ -901,18 +902,22 @@ public class ConverterUtil {
 
             int milliSecondPartLength = 0;
 
-            if (source.length() > 19)  {
+            if (source.length() == 19) {
+                haveTimeZone = false;
+            } else {
                 String rest = source.substring(19);
                 if (rest.startsWith(".")) {
                     // i.e this have the ('.'s+) part
                     if (rest.endsWith("Z")) {
                         // this is in gmt time zone
+                        haveTimeZone = true;
                         timeZoneOffSet = 0;
                         calendar.setTimeZone(TimeZone.getTimeZone("GMT"));
                         miliSecond = Integer.parseInt(rest.substring(1, rest.lastIndexOf("Z")));
                         milliSecondPartLength = rest.substring(1,rest.lastIndexOf("Z")).trim().length();
                     } else if ((rest.lastIndexOf("+") > 0) || (rest.lastIndexOf("-") > 0)) {
                         // this is given in a general time zione
+                        haveTimeZone = true;
                         String timeOffSet = null;
                         if (rest.lastIndexOf("+") > 0) {
                             timeOffSet = rest.substring(rest.lastIndexOf("+") + 1);
@@ -938,6 +943,7 @@ public class ConverterUtil {
 
                     } else {
                         // i.e it does not have time zone
+                        haveTimeZone = false;
                         miliSecond = Integer.parseInt(rest.substring(1));
                         milliSecondPartLength = rest.substring(1).trim().length();
                     }
@@ -946,9 +952,11 @@ public class ConverterUtil {
                     if (rest.startsWith("Z")) {
                         calendar.setTimeZone(TimeZone.getTimeZone("GMT"));
                         // this is in gmt time zone
+                        haveTimeZone = true;
                         timeZoneOffSet = 0;
                     } else if (rest.startsWith("+") || rest.startsWith("-")) {
                         // this is given in a general time zione
+                        haveTimeZone = true;
                         if (rest.charAt(3) != ':') {
                             throw new RuntimeException("invalid time zone format (" + source
                                     + ") without : at correct place");
@@ -982,12 +990,14 @@ public class ConverterUtil {
             }
             calendar.set(Calendar.MILLISECOND, (int)miliSecond);
             calendar.set(Calendar.ZONE_OFFSET, timeZoneOffSet);
-            calendar.set(Calendar.DST_OFFSET, 0);
-
+            // set the day light offset only if the time zone is present
+            if (haveTimeZone) {
+                calendar.set(Calendar.DST_OFFSET, 0);
+            }
 
 
         } else {
-            throw new NumberFormatException("date string can not be less than 19 charactors");
+            throw new NumberFormatException("date string can not be less than 19 characters");
         }
 
         return calendar;
diff --git a/modules/adb/test/org/apache/axis2/databinding/utils/ConverterUtilTest.java b/modules/adb/test/org/apache/axis2/databinding/utils/ConverterUtilTest.java
index fc5ef08..49e62d6 100644
--- a/modules/adb/test/org/apache/axis2/databinding/utils/ConverterUtilTest.java
+++ b/modules/adb/test/org/apache/axis2/databinding/utils/ConverterUtilTest.java
@@ -84,53 +84,312 @@ public class ConverterUtilTest extends TestCase {
         assertTrue(convertedObj.getClass().equals(boolean[].class));
 
     }
+    
+    /**
+     * Used to by formatCalendar* to format millisecond field.
+     * @param millis the millisecond value
+     * @param digits the number of digits to use
+     *        (0=none)
+     * @return something like ".123" or "" (when digits=0)
+     */
+    private static String formatMillis(int millis, int digits) {
+        if (digits == 0) return "";
+        StringBuffer sb = new StringBuffer(16);
+        sb.append('.');
+        sb.append(millis);
+        while( sb.length() > digits && sb.charAt(sb.length()-1) == '0' ) {
+            sb.deleteCharAt(sb.length()-1); // remove trailing '0'
+        }
+        while( sb.length() < digits+1 ) {
+            sb.append('0'); // add trailing '0'
+        }
+        return sb.toString();
+    }
 
-    public void testConvertToDateTime() {
+    /**
+     * Format a Calendar object to a schema datetime string.
+     * Used by testConvertToDateTime().
+     * @param c the object to format
+     * @param millisDigits number of digits used for millisecond field
+     *                     (0 = none)
+     * @param tz the time zone to use (null = default time zone)
+     * @return something like "1111-22-33T44:55:66.789"
+     */
+    private static String formatCalendarXsd(Calendar c, int millisDigits, TimeZone tz)
+    {
+        String formatString = "yyyy-MM-dd'T'HH:mm:ss";
+        SimpleDateFormat simpleDateFormat = new SimpleDateFormat(formatString);
+        if (tz != null) simpleDateFormat.setTimeZone(tz);
+        StringBuffer sb = new StringBuffer(simpleDateFormat.format(c.getTime()));
+        sb.append(formatMillis(c.get(Calendar.MILLISECOND), millisDigits));
+        return sb.toString();
+    }
 
-        SimpleDateFormat simpleDateFormat = new SimpleDateFormat("yyyy-MM-dd'T'HH:mm:ss.SSSZ");
-        Calendar calendar;
-
-        calendar = ConverterUtil.convertToDateTime("2007-02-15T14:54:29");
-        System.out.println("String   ==> " + "2007-02-15T14:54:29");
-        System.out.println("calendar ==> " + simpleDateFormat.format(calendar.getTime()));
-        System.out.println("calendar ==> " + ConverterUtil.convertToString(calendar));
-
-        calendar = ConverterUtil.convertToDateTime("2007-02-15T14:54:29.399");
-        System.out.println("String   ==> " + "2007-02-15T14:54:29.399");
-        System.out.println("calendar ==> " + simpleDateFormat.format(calendar.getTime()));
-        System.out.println("calendar ==> " + ConverterUtil.convertToString(calendar));
-
-        calendar = ConverterUtil.convertToDateTime("2007-02-15T14:54:29+05:30");
-        System.out.println("String   ==> " + "2007-02-15T14:54:29+05:30");
-        System.out.println("calendar ==> " + simpleDateFormat.format(calendar.getTime()));
-        System.out.println("calendar ==> " + ConverterUtil.convertToString(calendar));
-
-        calendar = ConverterUtil.convertToDateTime("2007-02-15T14:54:29.399+05:30");
-        System.out.println("String   ==> " + "2007-02-15T14:54:29.399+05:30");
-        System.out.println("calendar ==> " + simpleDateFormat.format(calendar.getTime()));
-        System.out.println("calendar ==> " + ConverterUtil.convertToString(calendar));
-
-        calendar = ConverterUtil.convertToDateTime("2007-02-15T14:54:29Z");
-        System.out.println("String   ==> " + "2007-02-15T14:54:29Z");
-        System.out.println("calendar ==> " + simpleDateFormat.format(calendar.getTime()));
-        System.out.println("calendar ==> " + ConverterUtil.convertToString(calendar));
-
-        calendar = ConverterUtil.convertToDateTime("2007-02-15T14:54:29.399Z");
-        System.out.println("String   ==> " + "2007-02-15T14:54:29.399Z");
-        System.out.println("calendar ==> " + simpleDateFormat.format(calendar.getTime()));
-        System.out.println("calendar ==> " + ConverterUtil.convertToString(calendar));
-
-        calendar = ConverterUtil.convertToDateTime("2006-12-11T23:57:16.625Z");
-        System.out.println("String   ==> " + "2006-12-11T23:57:16.625Z");
+    /**
+     * Format a Calendar object to a schema datetime string with time zone
+     * Used by testConvertToDateTime().
+     * @param c the object to format
+     * @param millisDigits number of digits used for millisecond field
+     *                     (0 = none)
+     * @param tz the timezone to use (null = default timezone)
+     * @return something like "1111-22-33T44:55:66.789+01:00"
+     */
+    private static String formatCalendarXsdWithTz(Calendar c, int millisDigits, TimeZone tz)
+    {
+        String formatString = "yyyy-MM-dd'T'HH:mm:ssZ";
+        SimpleDateFormat simpleDateFormat = new SimpleDateFormat(formatString);
+        if (tz != null) simpleDateFormat.setTimeZone(tz);
+        StringBuffer sb = new StringBuffer(simpleDateFormat.format(c.getTime()));
+        sb.insert(19, formatMillis(c.get(Calendar.MILLISECOND), millisDigits));
+        return sb.insert(sb.length()-2, ':').toString(); // fix tz format
+    }
+    
+    /**
+     * Format a Calendar object to a schema datetime string with time zone UTC
+     * Used by testConvertToDateTime().
+     * @param c the object to format
+     * @param millisDigits number of digits used for millisecond field
+     *                     (0 = none)
+     * @return something like "1111-22-33T44:55:66.789Z"
+     */
+    private static String formatCalendarXsdZulu(Calendar c, int millisDigits)
+    {
+        String formatString = "yyyy-MM-dd'T'HH:mm:ss";
+        SimpleDateFormat simpleDateFormat = new SimpleDateFormat(formatString);
         simpleDateFormat.setTimeZone(TimeZone.getTimeZone("GMT"));
-        System.out.println("calendar ==> " + simpleDateFormat.format(calendar.getTime()));
-        System.out.println("calendar ==> " + ConverterUtil.convertToString(calendar));
-
-        calendar = ConverterUtil.convertToDateTime("2007-02-15T14:54:29.399-05:30");
-        System.out.println("String   ==> " + "2007-02-15T14:54:29.399-05:30");
-        System.out.println("calendar ==> " + simpleDateFormat.format(calendar.getTime()));
-        System.out.println("calendar ==> " + ConverterUtil.convertToString(calendar));
+        StringBuffer sb = new StringBuffer(simpleDateFormat.format(c.getTime()));
+        sb.append(formatMillis(c.get(Calendar.MILLISECOND), millisDigits));
+        sb.append('Z');
+        return sb.toString();
+    }
+    
+    private void internalTestConvertToDateTime()
+    {
+        System.out.println("testing with TimeZone "
+                + TimeZone.getDefault().getDisplayName());
+        System.out.println("uses daylight time: "
+                + TimeZone.getDefault().useDaylightTime());
+        System.out.println("we are in daylight time: "
+                + TimeZone.getDefault().inDaylightTime(new Date()));
+
+        String testValue;  // holds the testvalue
+        TimeZone timeZone; // the (custom) time zone of testvalue
+        Calendar calendar; // the value to test
+        String back;       // the value converted back by convertToString
+        
+        // local date without daylight savings in "Europe/Berlin"
+        testValue = "2007-02-15T14:54:29";
+        timeZone = null;
+        calendar = ConverterUtil.convertToDateTime(testValue);
+        back = ConverterUtil.convertToString(calendar);
+        System.out.println("testValue ==> " + testValue);
+        System.out.println("calendar  ==> " + formatCalendarXsdWithTz(calendar, 0, null));
+        System.out.println("back      ==> " + back);
+        assertEquals(testValue, 
+                     formatCalendarXsd(calendar, 0, null));
+        assertEquals("should be in local timezone",
+                     TimeZone.getDefault().getOffset(calendar.getTimeInMillis()),
+                     calendar.get(Calendar.ZONE_OFFSET)+calendar.get(Calendar.DST_OFFSET));
+
+        // local date with daylight savings in "Europe/Berlin"
+        testValue = "2007-05-27T23:20:33";
+        timeZone = null;
+        calendar = ConverterUtil.convertToDateTime(testValue);
+        back = ConverterUtil.convertToString(calendar);
+        System.out.println("testValue ==> " + testValue);
+        System.out.println("calendar  ==> " + formatCalendarXsdWithTz(calendar, 0, null));
+        System.out.println("back      ==> " + back);
+        assertEquals(testValue, 
+                     formatCalendarXsd(calendar, 0, null));
+        assertEquals("should be in local timezone",
+                     TimeZone.getDefault().getOffset(calendar.getTimeInMillis()),
+                     calendar.get(Calendar.ZONE_OFFSET)+calendar.get(Calendar.DST_OFFSET));
+
+        // local date with milliseconds without daylight savings
+        testValue = "2007-02-15T14:54:29.399";
+        timeZone = null;
+        calendar = ConverterUtil.convertToDateTime(testValue);
+        back = ConverterUtil.convertToString(calendar);
+        System.out.println("testValue ==> " + testValue);
+        System.out.println("calendar  ==> " + formatCalendarXsdWithTz(calendar, 3, null));
+        System.out.println("back      ==> " + back);
+        assertEquals(testValue,
+                     formatCalendarXsd(calendar, 3, null));
+        assertEquals("should be in local timezone",
+                     TimeZone.getDefault().getOffset(calendar.getTimeInMillis()),
+                     calendar.get(Calendar.ZONE_OFFSET)+calendar.get(Calendar.DST_OFFSET));
+
+        // local date with milliseconds with daylight savings
+        testValue = "2009-06-12T23:20:33.2";
+        timeZone = null;
+        calendar = ConverterUtil.convertToDateTime(testValue);
+        back = ConverterUtil.convertToString(calendar);
+        System.out.println("testValue ==> " + testValue);
+        System.out.println("calendar  ==> " + formatCalendarXsdWithTz(calendar, 1, null));
+        System.out.println("back      ==> " + back);
+        assertEquals(testValue, 
+                     formatCalendarXsd(calendar, 1, null));
+        assertEquals("should be in local timezone",
+                     TimeZone.getDefault().getOffset(calendar.getTimeInMillis()),
+                     calendar.get(Calendar.ZONE_OFFSET)+calendar.get(Calendar.DST_OFFSET));
+
+        // date with time zone (positive) no milliseconds
+        testValue = "2007-02-15T14:54:29+05:30";
+        timeZone = TimeZone.getTimeZone("GMT+05:30"); //custom time zone
+        calendar = ConverterUtil.convertToDateTime(testValue);
+        back = ConverterUtil.convertToString(calendar);
+        System.out.println("testValue ==> " + testValue);
+        System.out.println("calendar  ==> " + formatCalendarXsdWithTz(calendar, 0, timeZone));
+        System.out.println("back      ==> " + back);
+        // make sure that timeZone.getRawOffset() is sufficient
+        assertFalse ("custom time zone should not use day light saving", 
+                     timeZone.useDaylightTime());
+        assertEquals(testValue, 
+                     formatCalendarXsdWithTz(calendar, 0, timeZone));
+        assertEquals("should be in timezone +05:30",
+                     timeZone.getRawOffset(),
+                     calendar.get(Calendar.ZONE_OFFSET)+calendar.get(Calendar.DST_OFFSET));
+
+        // date with time zone (negative) with milliseconds
+        testValue = "2007-02-15T14:54:29.399-05:30";
+        timeZone = TimeZone.getTimeZone("GMT-05:30"); //custom time zone
+        calendar = ConverterUtil.convertToDateTime(testValue);
+        back = ConverterUtil.convertToString(calendar);
+        System.out.println("testValue ==> " + testValue);
+        System.out.println("calendar  ==> " + formatCalendarXsdWithTz(calendar, 3, timeZone));
+        System.out.println("back      ==> " + back);
+        // make sure that timeZone.getRawOffset() is sufficient
+        assertFalse ("custom time zone should not use day light saving", 
+                     timeZone.useDaylightTime());
+        assertEquals(testValue, 
+                     formatCalendarXsdWithTz(calendar, 3, timeZone));
+        assertEquals("should be in timezone -05:30",
+                     timeZone.getRawOffset(),
+                     calendar.get(Calendar.ZONE_OFFSET)+calendar.get(Calendar.DST_OFFSET));
+
+        // date with time zone and milliseconds
+        testValue = "2007-02-15T14:54:29.399+05:30";
+        timeZone = TimeZone.getTimeZone("GMT+05:30"); //custom time zone
+        calendar = ConverterUtil.convertToDateTime(testValue);
+        back = ConverterUtil.convertToString(calendar);
+        System.out.println("testValue ==> " + testValue);
+        System.out.println("calendar  ==> " + formatCalendarXsdWithTz(calendar, 3, timeZone));
+        System.out.println("back      ==> " + back);
+        // make sure that timeZone.getRawOffset() is sufficient
+        assertFalse ("custom time zone should not use day light saving", 
+                     timeZone.useDaylightTime());
+        assertEquals(testValue, 
+                     formatCalendarXsdWithTz(calendar, 3, timeZone));
+        assertEquals("should be in timezone +05:30",
+                     timeZone.getRawOffset(),
+                     calendar.get(Calendar.ZONE_OFFSET)+calendar.get(Calendar.DST_OFFSET));
+
+        // date within UTC (Zulu time zone)
+        testValue = "2007-02-15T14:54:29Z";
+        timeZone = TimeZone.getTimeZone("GMT"); //UTC time zone
+        calendar = ConverterUtil.convertToDateTime(testValue);
+        back = ConverterUtil.convertToString(calendar);
+        System.out.println("testValue ==> " + testValue);
+        System.out.println("calendar  ==> " + formatCalendarXsdWithTz(calendar, 0, timeZone));
+        System.out.println("back      ==> " + back);
+        assertEquals(testValue, 
+                     formatCalendarXsdZulu(calendar,0));
+        assertEquals("should be in UTC",
+                     0,
+                     calendar.get(Calendar.ZONE_OFFSET)+calendar.get(Calendar.DST_OFFSET));
+
+        // date within UTC (Zulu time zone) with milliseconds
+        testValue = "2007-02-15T14:54:29.399Z";
+        timeZone = TimeZone.getTimeZone("GMT"); //UTC time zone
+        calendar = ConverterUtil.convertToDateTime(testValue);
+        back = ConverterUtil.convertToString(calendar);
+        System.out.println("testValue ==> " + testValue);
+        System.out.println("calendar  ==> " + formatCalendarXsdWithTz(calendar, 3, timeZone));
+        System.out.println("back      ==> " + back);
+        assertEquals(testValue, 
+                     formatCalendarXsdZulu(calendar, 3));
+        assertEquals("should be in UTC",
+                     0,
+                     calendar.get(Calendar.ZONE_OFFSET)+calendar.get(Calendar.DST_OFFSET));
+
+        // date within UTC (Zulu time zone) with milliseconds
+        testValue = "2006-12-11T23:57:16.62Z";
+        timeZone = TimeZone.getTimeZone("GMT"); //UTC time zone
+        calendar = ConverterUtil.convertToDateTime(testValue);
+        back = ConverterUtil.convertToString(calendar);
+        System.out.println("testValue ==> " + testValue);
+        System.out.println("calendar  ==> " + formatCalendarXsdWithTz(calendar, 2, timeZone));
+        System.out.println("back      ==> " + back);
+        assertEquals(testValue, 
+                     formatCalendarXsdZulu(calendar, 2));
+        assertEquals("should be in UTC",
+                     0,
+                     calendar.get(Calendar.ZONE_OFFSET)+calendar.get(Calendar.DST_OFFSET));
+
+        // date within UTC (Zulu time zone) with milliseconds
+        testValue = "2012-05-18T13:57:01.7Z";
+        timeZone = TimeZone.getTimeZone("GMT"); //UTC time zone
+        calendar = ConverterUtil.convertToDateTime(testValue);
+        back = ConverterUtil.convertToString(calendar);
+        System.out.println("testValue ==> " + testValue);
+        System.out.println("calendar  ==> " + formatCalendarXsdWithTz(calendar, 1, timeZone));
+        System.out.println("back      ==> " + back);
+        assertEquals(testValue, 
+                     formatCalendarXsdZulu(calendar, 1));
+        assertEquals("should be in UTC",
+                     0,
+                     calendar.get(Calendar.ZONE_OFFSET)+calendar.get(Calendar.DST_OFFSET));
+
+        // date within UTC (Zulu time zone) with milliseconds
+        testValue = "2012-05-17T13:57:01.123000000Z";
+        timeZone = TimeZone.getTimeZone("GMT"); //UTC time zone
+        calendar = ConverterUtil.convertToDateTime(testValue);
+        back = ConverterUtil.convertToString(calendar);
+        System.out.println("testValue ==> " + testValue);
+        System.out.println("calendar  ==> " + formatCalendarXsdWithTz(calendar, 9, timeZone));
+        System.out.println("back      ==> " + back);
+        assertEquals(testValue, 
+                     formatCalendarXsdZulu(calendar, 9));
+        assertEquals("should be in UTC",
+                     0,
+                     calendar.get(Calendar.ZONE_OFFSET)+calendar.get(Calendar.DST_OFFSET));        
+    }
 
+    public void testConvertToDateTime() {
+        TimeZone currentTimeZone = TimeZone.getDefault();
+        System.out.println("before  Test: TimeZone is "+TimeZone.getDefault().getDisplayName());
+        try {
+            // run tests with default JVM time zone
+            this.internalTestConvertToDateTime();
+
+            // We use two time zone with GMT+1. One north and one south. 
+            // We hope that one is currently using daylight savings and the
+            // other is not using it.
+
+            // run tests with time zone "Europe/Berlin"
+            System.out.println( "setting time zone to Europe/Berlin" );
+            TimeZone.setDefault(TimeZone.getTimeZone("Europe/Berlin"));
+            this.internalTestConvertToDateTime();
+            
+            // run tests with time zone "Africa/Windhoek"
+            System.out.println( "setting time zone to Africa/Windhoek" );
+            TimeZone.setDefault(TimeZone.getTimeZone("Africa/Windhoek"));
+            this.internalTestConvertToDateTime();
+
+            // run tests with time zone "Australia/Darwin"
+            System.out.println( "setting time zone to Australia/Darwin" );
+            TimeZone.setDefault(TimeZone.getTimeZone("Australia/Darwin"));
+            this.internalTestConvertToDateTime();
+                        
+            // run tests with time zone "US/Mountain"
+            System.out.println( "setting time zone to US/Mountain" );
+            TimeZone.setDefault(TimeZone.getTimeZone("US/Mountain"));
+            this.internalTestConvertToDateTime();
+
+        } finally {
+            TimeZone.setDefault( currentTimeZone );
+            System.out.println("after   Test: TimeZone is "+TimeZone.getDefault().getDisplayName());
+        }
     }
 
     public void testConvertToDateString() {
@@ -167,7 +426,7 @@ public class ConverterUtilTest extends TestCase {
         Calendar c = Calendar.getInstance(timeZone);
         c.clear();
         c.set(2008, Calendar.JANUARY, 1);
-        TestCase.assertTrue(ConverterUtil.convertToString(c).endsWith("+08:00"));
+        //FIXME       TestCase.assertTrue(ConverterUtil.convertToString(c).endsWith("+08:00"));
         
     }
 


[axis-axis2-java-core] 09/38: Merged r1190469 to the 1.5 branch.

Posted by bi...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

billblough pushed a commit to branch 1_5
in repository https://gitbox.apache.org/repos/asf/axis-axis2-java-core.git

commit 7ed1570ac8c39bc478b21e198f48b2c512231a61
Author: Andreas Veithen <ve...@apache.org>
AuthorDate: Fri Oct 28 17:53:48 2011 +0000

    Merged r1190469 to the 1.5 branch.
---
 modules/saaj/src/org/apache/axis2/saaj/SOAPEnvelopeImpl.java | 3 ++-
 1 file changed, 2 insertions(+), 1 deletion(-)

diff --git a/modules/saaj/src/org/apache/axis2/saaj/SOAPEnvelopeImpl.java b/modules/saaj/src/org/apache/axis2/saaj/SOAPEnvelopeImpl.java
index 044532a..2f9032c 100644
--- a/modules/saaj/src/org/apache/axis2/saaj/SOAPEnvelopeImpl.java
+++ b/modules/saaj/src/org/apache/axis2/saaj/SOAPEnvelopeImpl.java
@@ -19,6 +19,7 @@
 
 package org.apache.axis2.saaj;
 
+import org.apache.axiom.om.OMNode;
 import org.apache.axiom.om.impl.dom.DocumentImpl;
 import org.apache.axiom.om.impl.dom.NodeImpl;
 import org.apache.axiom.om.impl.dom.TextImpl;
@@ -197,7 +198,7 @@ public class SOAPEnvelopeImpl extends SOAPElementImpl implements javax.xml.soap.
         } else {
             // Else this is a header
             TextImpl doomText = new TextImpl(text, this.element.getOMFactory());
-            doomText.setNextOMSibling((NodeImpl)firstChild);
+            doomText.setNextOMSibling((OMNode)firstChild);
             doomText.setPreviousOMSibling(null);
             element.setFirstChild(doomText);
             ((NodeImpl)firstChild).setPreviousOMSibling(doomText);


[axis-axis2-java-core] 19/38: Merged r1296062 to the 1.5 branch.

Posted by bi...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

billblough pushed a commit to branch 1_5
in repository https://gitbox.apache.org/repos/asf/axis-axis2-java-core.git

commit 6de603584232ef75241f7f9b9b4f9635719e6cb8
Author: Andreas Veithen <ve...@apache.org>
AuthorDate: Sun Mar 4 11:29:09 2012 +0000

    Merged r1296062 to the 1.5 branch.
---
 modules/saaj/src/org/apache/axis2/saaj/SOAPEnvelopeImpl.java | 3 ++-
 1 file changed, 2 insertions(+), 1 deletion(-)

diff --git a/modules/saaj/src/org/apache/axis2/saaj/SOAPEnvelopeImpl.java b/modules/saaj/src/org/apache/axis2/saaj/SOAPEnvelopeImpl.java
index 2f9032c..328fae0 100644
--- a/modules/saaj/src/org/apache/axis2/saaj/SOAPEnvelopeImpl.java
+++ b/modules/saaj/src/org/apache/axis2/saaj/SOAPEnvelopeImpl.java
@@ -20,6 +20,7 @@
 package org.apache.axis2.saaj;
 
 import org.apache.axiom.om.OMNode;
+import org.apache.axiom.om.impl.dom.ChildNode;
 import org.apache.axiom.om.impl.dom.DocumentImpl;
 import org.apache.axiom.om.impl.dom.NodeImpl;
 import org.apache.axiom.om.impl.dom.TextImpl;
@@ -201,7 +202,7 @@ public class SOAPEnvelopeImpl extends SOAPElementImpl implements javax.xml.soap.
             doomText.setNextOMSibling((OMNode)firstChild);
             doomText.setPreviousOMSibling(null);
             element.setFirstChild(doomText);
-            ((NodeImpl)firstChild).setPreviousOMSibling(doomText);
+            ((ChildNode)firstChild).setPreviousOMSibling(doomText);
         }
         return this;
     }


[axis-axis2-java-core] 33/38: AXIS2-5349 - Merged r1352413 to 1.5 branch.

Posted by bi...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

billblough pushed a commit to branch 1_5
in repository https://gitbox.apache.org/repos/asf/axis-axis2-java-core.git

commit 18e5409e057ac93da954fb6397f70ba770376e63
Author: Sagara Gunathunga <sa...@apache.org>
AuthorDate: Thu Jun 21 05:44:39 2012 +0000

    AXIS2-5349 - Merged r1352413 to 1.5 branch.
---
 .../src/org/apache/axis2/wsdl/template/c/SkelHeaderTemplate.xsl      | 4 ++++
 .../src/org/apache/axis2/wsdl/template/c/StubHeaderTemplate.xsl      | 5 +++++
 2 files changed, 9 insertions(+)

diff --git a/modules/codegen/src/org/apache/axis2/wsdl/template/c/SkelHeaderTemplate.xsl b/modules/codegen/src/org/apache/axis2/wsdl/template/c/SkelHeaderTemplate.xsl
index 9ad532b..729cd87 100644
--- a/modules/codegen/src/org/apache/axis2/wsdl/template/c/SkelHeaderTemplate.xsl
+++ b/modules/codegen/src/org/apache/axis2/wsdl/template/c/SkelHeaderTemplate.xsl
@@ -32,6 +32,8 @@
      * <xsl:value-of select="@name"/> Axis2/C skeleton for the axisService- Header file
      */
 
+    #ifndef <xsl:value-of select="$caps_svc_name"/>_H
+    #define <xsl:value-of select="$caps_svc_name"/>_H
 
 	#include &lt;axis2_svc_skeleton.h&gt;
 	#include &lt;axutil_log_default.h&gt;
@@ -115,5 +117,7 @@
 	#ifdef __cplusplus
 	}
 	#endif
+
+    #endif
     </xsl:template>
  </xsl:stylesheet>
diff --git a/modules/codegen/src/org/apache/axis2/wsdl/template/c/StubHeaderTemplate.xsl b/modules/codegen/src/org/apache/axis2/wsdl/template/c/StubHeaderTemplate.xsl
index ed76f7a..7a58e55 100644
--- a/modules/codegen/src/org/apache/axis2/wsdl/template/c/StubHeaderTemplate.xsl
+++ b/modules/codegen/src/org/apache/axis2/wsdl/template/c/StubHeaderTemplate.xsl
@@ -38,6 +38,9 @@
         * by the Apache Axis2/Java version: #axisVersion# #today#
         */
 
+        #ifndef <xsl:value-of select="$caps_name"/>_H
+        #define <xsl:value-of select="$caps_name"/>_H
+
         #include &lt;stdio.h&gt;
         #include &lt;axiom.h&gt;
         #include &lt;axutil_utils.h&gt;
@@ -241,5 +244,7 @@
 	#ifdef __cplusplus
 	}
 	#endif
+
+    #endif
    </xsl:template>
 </xsl:stylesheet>


[axis-axis2-java-core] 06/38: Switched Axiom to 1.2.13-SNAPSHOT.

Posted by bi...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

billblough pushed a commit to branch 1_5
in repository https://gitbox.apache.org/repos/asf/axis-axis2-java-core.git

commit 0847de1fb329154cb489cae7cad8923f6909d318
Author: Andreas Veithen <ve...@apache.org>
AuthorDate: Sat Oct 1 22:29:32 2011 +0000

    Switched Axiom to 1.2.13-SNAPSHOT.
---
 modules/parent/pom.xml | 3 ++-
 1 file changed, 2 insertions(+), 1 deletion(-)

diff --git a/modules/parent/pom.xml b/modules/parent/pom.xml
index 5e467a2..30b02b9 100644
--- a/modules/parent/pom.xml
+++ b/modules/parent/pom.xml
@@ -68,7 +68,8 @@
     <properties>
         <ant.version>1.7.0</ant.version>
         <antlr.version>2.7.7</antlr.version>
-        <axiom.version>1.2.12</axiom.version>
+        <!-- Need to ship Axis2 1.5.7 with Axiom 1.2.13 because of RAMPART-336 -->
+        <axiom.version>1.2.13-SNAPSHOT</axiom.version>
         <bsf.version>2.4.0</bsf.version>
         <commons.codec.version>1.3</commons.codec.version>
         <commons.fileupload.version>1.2</commons.fileupload.version>


[axis-axis2-java-core] 22/38: Merged r1298550 to the 1.5 branch.

Posted by bi...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

billblough pushed a commit to branch 1_5
in repository https://gitbox.apache.org/repos/asf/axis-axis2-java-core.git

commit 04a183ee9709a1e8bb285deb0fdaef6e052441e4
Author: Andreas Veithen <ve...@apache.org>
AuthorDate: Sat Mar 10 09:32:20 2012 +0000

    Merged r1298550 to the 1.5 branch.
---
 modules/saaj/src/org/apache/axis2/saaj/TextImplEx.java | 5 +++++
 1 file changed, 5 insertions(+)

diff --git a/modules/saaj/src/org/apache/axis2/saaj/TextImplEx.java b/modules/saaj/src/org/apache/axis2/saaj/TextImplEx.java
index f846d3c..ebd0fae 100644
--- a/modules/saaj/src/org/apache/axis2/saaj/TextImplEx.java
+++ b/modules/saaj/src/org/apache/axis2/saaj/TextImplEx.java
@@ -24,6 +24,7 @@ import org.apache.axiom.om.OMException;
 import org.apache.axiom.om.impl.dom.DOOMAbstractFactory;
 import org.apache.axiom.om.impl.dom.TextImpl;
 import org.w3c.dom.DOMException;
+import org.w3c.dom.Document;
 
 import javax.xml.soap.SOAPElement;
 import javax.xml.soap.Text;
@@ -242,6 +243,10 @@ public class TextImplEx extends NodeImplEx implements Text {
         textNode.setParent(element);
     }
 
+    public Document getOwnerDocument() {
+        return textNode.getOwnerDocument();
+    }
+
     /* (non-Javadoc)
       * @see org.apache.axiom.om.OMNode#getParent()
       */


[axis-axis2-java-core] 07/38: Backported r795789 and part of r1042244 to the 1.5 branch to reduce the coupling to Axiom internals. This should solve AXIS2-4363 and AXIS2-4387.

Posted by bi...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

billblough pushed a commit to branch 1_5
in repository https://gitbox.apache.org/repos/asf/axis-axis2-java-core.git

commit e929313a2986b02a9ff867456c38c1a954bf98c9
Author: Andreas Veithen <ve...@apache.org>
AuthorDate: Sat Oct 15 20:53:41 2011 +0000

    Backported r795789 and part of r1042244 to the 1.5 branch to reduce the coupling to Axiom internals. This should solve AXIS2-4363 and AXIS2-4387.
---
 .../axis2/schema/template/ADBBeanTemplate.xsl      | 194 +--------------------
 .../types/soapencoding/Base64Binary.java           |  42 +----
 .../axis2/databinding/types/xsd/Base64Binary.java  |  26 +--
 .../axis2/databinding/utils/ConverterUtil.java     |  29 +--
 4 files changed, 12 insertions(+), 279 deletions(-)

diff --git a/modules/adb-codegen/src/org/apache/axis2/schema/template/ADBBeanTemplate.xsl b/modules/adb-codegen/src/org/apache/axis2/schema/template/ADBBeanTemplate.xsl
index 03fd807..2daa034 100644
--- a/modules/adb-codegen/src/org/apache/axis2/schema/template/ADBBeanTemplate.xsl
+++ b/modules/adb-codegen/src/org/apache/axis2/schema/template/ADBBeanTemplate.xsl
@@ -692,20 +692,6 @@
             }
         </xsl:if>
 
-     /**
-     * isReaderMTOMAware
-     * @return true if the reader supports MTOM
-     */
-   public static boolean isReaderMTOMAware(javax.xml.stream.XMLStreamReader reader) {
-        boolean isReaderMTOMAware = false;
-        <!-- workaround for the issues in the wstx reader!-->
-        try{
-          isReaderMTOMAware = java.lang.Boolean.TRUE.equals(reader.getProperty(org.apache.axiom.om.OMConstants.IS_DATA_HANDLERS_AWARE));
-        }catch(java.lang.IllegalArgumentException e){
-          isReaderMTOMAware = false;
-        }
-        return isReaderMTOMAware;
-   }
      <!-- ######################################################################################### -->
      <!-- get OMElement methods that allows direct writing -->
         /**
@@ -3052,33 +3038,7 @@
                                                   } else {
                                                 </xsl:if>
 
-                                                    if (isReaderMTOMAware(reader)
-                                                            &amp;&amp;
-                                                            java.lang.Boolean.TRUE.equals(reader.getProperty(org.apache.axiom.om.OMConstants.IS_BINARY)))
-                                                    {
-                                                        //MTOM aware reader - get the datahandler directly and put it in the object
-                                                        <xsl:value-of select="$listName"/>.add(
-                                                                (javax.activation.DataHandler) reader.getProperty(org.apache.axiom.om.OMConstants.DATA_HANDLER));
-                                                    } else {
-                                                        // Step in
-                                                        if (reader.getEventType() == javax.xml.stream.XMLStreamConstants.START_ELEMENT &amp;&amp; <xsl:value-of select="$propQName"/>.equals(reader.getName())) {
-                                                            reader.next();
-                                                        }
-                                                        if (reader.getEventType() == javax.xml.stream.XMLStreamConstants.START_ELEMENT &amp;&amp; reader.getName().equals(new javax.xml.namespace.QName(org.apache.axiom.om.impl.MTOMConstants.XOP_NAMESPACE_URI, org.apache.axiom.om.impl.MTOMConstants.XOP_INCLUDE)))
-                                                        {
-                                                            java.lang.String id = org.apache.axiom.om.util.ElementHelper.getContentID(reader, "UTF-8");
-                                                            <xsl:value-of select="$listName"/>.add(((org.apache.axiom.soap.impl.builder.MTOMStAXSOAPModelBuilder) ((org.apache.axiom.om.impl.llom.OMStAXWrapper) reader).getBuilder()).getDataHandler(id));
-                                                            reader.next();
-                                                            reader.next();
-                                                        } else if(reader.hasText()) {
-                                                            //Do the usual conversion
-                                                            java.lang.String content = reader.getText();
-                                                            <xsl:value-of select="$listName"/>.add(
-                                                                    org.apache.axis2.databinding.utils.ConverterUtil.convertToBase64Binary(content));
-                                                                    reader.next();
-                                                        }
-
-                                                    }
+                                                    <xsl:value-of select="$listName"/>.add(org.apache.axiom.util.stax.XMLStreamReaderUtils.getDataHandlerFromElement(reader));
 
 
                                                 <xsl:if test="@nillable">}</xsl:if>
@@ -3107,30 +3067,7 @@
                                                               } else {
                                                             </xsl:if>
 
-                                                                <xsl:if test="not($simple)">reader.next();</xsl:if>
-                                                                if (isReaderMTOMAware(reader)
-                                                                        &amp;&amp;
-                                                                        java.lang.Boolean.TRUE.equals(reader.getProperty(org.apache.axiom.om.OMConstants.IS_BINARY)))
-                                                                {
-                                                                    //MTOM aware reader - get the datahandler directly and put it in the object
-                                                                    <xsl:value-of select="$listName"/>.add(
-                                                                            (javax.activation.DataHandler) reader.getProperty(org.apache.axiom.om.OMConstants.DATA_HANDLER));
-                                                                } else {
-                                                                    if (reader.getEventType() == javax.xml.stream.XMLStreamConstants.START_ELEMENT &amp;&amp; reader.getName().equals(new javax.xml.namespace.QName(org.apache.axiom.om.impl.MTOMConstants.XOP_NAMESPACE_URI, org.apache.axiom.om.impl.MTOMConstants.XOP_INCLUDE)))
-                                                                    {
-                                                                        java.lang.String id = org.apache.axiom.om.util.ElementHelper.getContentID(reader, "UTF-8");
-                                                                        <xsl:value-of select="$listName"/>.add(((org.apache.axiom.soap.impl.builder.MTOMStAXSOAPModelBuilder) ((org.apache.axiom.om.impl.llom.OMStAXWrapper) reader).getBuilder()).getDataHandler(id));
-                                                                        reader.next();
-                                                                        reader.next();
-                                                                    } else if(reader.hasText()) {
-                                                                        //Do the usual conversion
-                                                                        java.lang.String content = reader.getText();
-                                                                        <xsl:value-of select="$listName"/>.add(
-                                                                                org.apache.axis2.databinding.utils.ConverterUtil.convertToBase64Binary(content));
-                                                                                reader.next();
-                                                                    }
-
-                                                                }
+                                                                <xsl:value-of select="$listName"/>.add(org.apache.axiom.util.stax.XMLStreamReaderUtils.getDataHandlerFromElement(reader));
 
                                                             <xsl:if test="@nillable">}</xsl:if>
                                                         }else{
@@ -3368,35 +3305,9 @@
                                 <!-- end of OMelement handling -->
                                 <!-- start of the simple types handling for binary content-->
                                 <xsl:when test="@binary">
-                                    <xsl:if test="not($simple)">reader.next();</xsl:if>
-                                    if (isReaderMTOMAware(reader)
-                                            &amp;&amp;
-                                            java.lang.Boolean.TRUE.equals(reader.getProperty(org.apache.axiom.om.OMConstants.IS_BINARY)))
-                                    {
-                                        //MTOM aware reader - get the datahandler directly and put it in the object
-                                        object.set<xsl:value-of select="$javaName"/>(
-                                                (javax.activation.DataHandler) reader.getProperty(org.apache.axiom.om.OMConstants.DATA_HANDLER));
-                                    } else {
-                                        if (reader.getEventType() == javax.xml.stream.XMLStreamConstants.START_ELEMENT &amp;&amp; reader.getName().equals(new javax.xml.namespace.QName(org.apache.axiom.om.impl.MTOMConstants.XOP_NAMESPACE_URI, org.apache.axiom.om.impl.MTOMConstants.XOP_INCLUDE)))
-                                        {
-                                            java.lang.String id = org.apache.axiom.om.util.ElementHelper.getContentID(reader, "UTF-8");
-                                            object.set<xsl:value-of select="$javaName"/>(((org.apache.axiom.soap.impl.builder.MTOMStAXSOAPModelBuilder) ((org.apache.axiom.om.impl.llom.OMStAXWrapper) reader).getBuilder()).getDataHandler(id));
-                                            reader.next();
-                                            <xsl:if test="($isType or $anon) and not($simple)">
-                                                reader.next();
-                                            </xsl:if>
-                                        } else if(reader.hasText()) {
-                                            //Do the usual conversion
-                                            java.lang.String content = reader.getText();
-                                            object.set<xsl:value-of select="$javaName"/>(
-                                                    org.apache.axis2.databinding.utils.ConverterUtil.convertToBase64Binary(content));
-                                            <xsl:if test="($isType or $anon) and not($simple)">
-                                                reader.next();
-                                            </xsl:if>
-                                        }
-                                    }
+                                    object.set<xsl:value-of select="$javaName"/>(org.apache.axiom.util.stax.XMLStreamReaderUtils.getDataHandlerFromElement(reader));
 
-                                    <xsl:if test="$isType or $anon">  <!-- This is a subelement property to be consumed -->
+                                    <xsl:if test="($isType or $anon) and not($simple)">  <!-- This is a subelement property to be consumed -->
                                         reader.next();
                                     </xsl:if>
                                 </xsl:when>
@@ -4129,20 +4040,6 @@ public <xsl:if test="not(@unwrapped) or (@skip-write)">static</xsl:if> class <xs
             return org.apache.axis2.databinding.utils.BeanUtil.getUniquePrefix();
         }
 
-        /**
-            * isReaderMTOMAware
-            * @return true if the reader supports MTOM
-            */
-          public static boolean isReaderMTOMAware(javax.xml.stream.XMLStreamReader reader) {
-               boolean isReaderMTOMAware = false;
-               <!-- workaround for the issues in the wstx reader!-->
-               try{
-                 isReaderMTOMAware = java.lang.Boolean.TRUE.equals(reader.getProperty(org.apache.axiom.om.OMConstants.IS_DATA_HANDLERS_AWARE));
-               }catch(java.lang.IllegalArgumentException e){
-                 isReaderMTOMAware = false;
-               }
-               return isReaderMTOMAware;
-          }
             <!-- ######################################################################################### -->
             <!-- get OMElement methods that allows direct writing -->
                /**
@@ -5343,33 +5240,7 @@ public <xsl:if test="not(@unwrapped) or (@skip-write)">static</xsl:if> class <xs
                                                   } else {
                                                 </xsl:if>
 
-                                                    if (isReaderMTOMAware(reader)
-                                                            &amp;&amp;
-                                                            java.lang.Boolean.TRUE.equals(reader.getProperty(org.apache.axiom.om.OMConstants.IS_BINARY)))
-                                                    {
-                                                        //MTOM aware reader - get the datahandler directly and put it in the object
-                                                        <xsl:value-of select="$listName"/>.add(
-                                                                (javax.activation.DataHandler) reader.getProperty(org.apache.axiom.om.OMConstants.DATA_HANDLER));
-                                                    } else {
-                                                        // Step in
-                                                        if (reader.getEventType() == javax.xml.stream.XMLStreamConstants.START_ELEMENT &amp;&amp; <xsl:value-of select="$propQName"/>.equals(reader.getName())) {
-                                                            reader.next();
-                                                        }
-                                                        if (reader.getEventType() == javax.xml.stream.XMLStreamConstants.START_ELEMENT &amp;&amp; reader.getName().equals(new javax.xml.namespace.QName(org.apache.axiom.om.impl.MTOMConstants.XOP_NAMESPACE_URI, org.apache.axiom.om.impl.MTOMConstants.XOP_INCLUDE)))
-                                                        {
-                                                            java.lang.String id = org.apache.axiom.om.util.ElementHelper.getContentID(reader, "UTF-8");
-                                                            <xsl:value-of select="$listName"/>.add(((org.apache.axiom.soap.impl.builder.MTOMStAXSOAPModelBuilder) ((org.apache.axiom.om.impl.llom.OMStAXWrapper) reader).getBuilder()).getDataHandler(id));
-                                                            reader.next();
-                                                            reader.next();
-                                                        } else if(reader.hasText()) {
-                                                            //Do the usual conversion
-                                                            java.lang.String content = reader.getText();
-                                                            <xsl:value-of select="$listName"/>.add(
-                                                                    org.apache.axis2.databinding.utils.ConverterUtil.convertToBase64Binary(content));
-                                                                    reader.next();
-                                                        }
-
-                                                    }
+                                                    <xsl:value-of select="$listName"/>.add(org.apache.axiom.util.stax.XMLStreamReaderUtils.getDataHandlerFromElement(reader));
 
 
                                                 <xsl:if test="@nillable">}</xsl:if>
@@ -5398,30 +5269,7 @@ public <xsl:if test="not(@unwrapped) or (@skip-write)">static</xsl:if> class <xs
                                                               } else {
                                                             </xsl:if>
 
-                                                                <xsl:if test="not($simple)">reader.next();</xsl:if>
-                                                                if (isReaderMTOMAware(reader)
-                                                                        &amp;&amp;
-                                                                        java.lang.Boolean.TRUE.equals(reader.getProperty(org.apache.axiom.om.OMConstants.IS_BINARY)))
-                                                                {
-                                                                    //MTOM aware reader - get the datahandler directly and put it in the object
-                                                                    <xsl:value-of select="$listName"/>.add(
-                                                                            (javax.activation.DataHandler) reader.getProperty(org.apache.axiom.om.OMConstants.DATA_HANDLER));
-                                                                } else {
-                                                                    if (reader.getEventType() == javax.xml.stream.XMLStreamConstants.START_ELEMENT &amp;&amp; reader.getName().equals(new javax.xml.namespace.QName(org.apache.axiom.om.impl.MTOMConstants.XOP_NAMESPACE_URI, org.apache.axiom.om.impl.MTOMConstants.XOP_INCLUDE)))
-                                                                    {
-                                                                        java.lang.String id = org.apache.axiom.om.util.ElementHelper.getContentID(reader, "UTF-8");
-                                                                        <xsl:value-of select="$listName"/>.add(((org.apache.axiom.soap.impl.builder.MTOMStAXSOAPModelBuilder) ((org.apache.axiom.om.impl.llom.OMStAXWrapper) reader).getBuilder()).getDataHandler(id));
-                                                                        reader.next();
-                                                                        reader.next();
-                                                                    } else if(reader.hasText()) {
-                                                                        //Do the usual conversion
-                                                                        java.lang.String content = reader.getText();
-                                                                        <xsl:value-of select="$listName"/>.add(
-                                                                                org.apache.axis2.databinding.utils.ConverterUtil.convertToBase64Binary(content));
-                                                                                reader.next();
-                                                                    }
-
-                                                                }
+                                                                <xsl:value-of select="$listName"/>.add(org.apache.axiom.util.stax.XMLStreamReaderUtils.getDataHandlerFromElement(reader));
 
                                                             <xsl:if test="@nillable">}</xsl:if>
                                                         }else{
@@ -5622,35 +5470,9 @@ public <xsl:if test="not(@unwrapped) or (@skip-write)">static</xsl:if> class <xs
                                 <!-- end of OMelement handling -->
                                 <!-- start of the simple types handling for binary content-->
                                 <xsl:when test="@binary">
-                                    <xsl:if test="not($simple)">reader.next();</xsl:if>
-                                    if (isReaderMTOMAware(reader)
-                                            &amp;&amp;
-                                            java.lang.Boolean.TRUE.equals(reader.getProperty(org.apache.axiom.om.OMConstants.IS_BINARY)))
-                                    {
-                                        //MTOM aware reader - get the datahandler directly and put it in the object
-                                        object.set<xsl:value-of select="$javaName"/>(
-                                                (javax.activation.DataHandler) reader.getProperty(org.apache.axiom.om.OMConstants.DATA_HANDLER));
-                                    } else {
-                                        if (reader.getEventType() == javax.xml.stream.XMLStreamConstants.START_ELEMENT &amp;&amp; reader.getName().equals(new javax.xml.namespace.QName(org.apache.axiom.om.impl.MTOMConstants.XOP_NAMESPACE_URI, org.apache.axiom.om.impl.MTOMConstants.XOP_INCLUDE)))
-                                        {
-                                            java.lang.String id = org.apache.axiom.om.util.ElementHelper.getContentID(reader, "UTF-8");
-                                            object.set<xsl:value-of select="$javaName"/>(((org.apache.axiom.soap.impl.builder.MTOMStAXSOAPModelBuilder) ((org.apache.axiom.om.impl.llom.OMStAXWrapper) reader).getBuilder()).getDataHandler(id));
-                                            reader.next();
-                                            <xsl:if test="($isType or $anon) and not($simple)">
-                                                reader.next();
-                                            </xsl:if>
-                                        } else if(reader.hasText()) {
-                                            //Do the usual conversion
-                                            java.lang.String content = reader.getText();
-                                            object.set<xsl:value-of select="$javaName"/>(
-                                                    org.apache.axis2.databinding.utils.ConverterUtil.convertToBase64Binary(content));
-                                            <xsl:if test="($isType or $anon) and not($simple)">
-                                                reader.next();
-                                            </xsl:if>
-                                        }
-                                    }
+                                    object.set<xsl:value-of select="$javaName"/>(org.apache.axiom.util.stax.XMLStreamReaderUtils.getDataHandlerFromElement(reader));
 
-                                    <xsl:if test="$isType or $anon">  <!-- This is a subelement property to be consumed -->
+                                    <xsl:if test="($isType or $anon) and not($simple)">  <!-- This is a subelement property to be consumed -->
                                         reader.next();
                                     </xsl:if>
                                 </xsl:when>
diff --git a/modules/adb/src/org/apache/axis2/databinding/types/soapencoding/Base64Binary.java b/modules/adb/src/org/apache/axis2/databinding/types/soapencoding/Base64Binary.java
index 8872ef2..1a97229 100644
--- a/modules/adb/src/org/apache/axis2/databinding/types/soapencoding/Base64Binary.java
+++ b/modules/adb/src/org/apache/axis2/databinding/types/soapencoding/Base64Binary.java
@@ -87,22 +87,6 @@
                             }
                         
 
-     /**
-     * isReaderMTOMAware
-     * @return true if the reader supports MTOM
-     */
-   public static boolean isReaderMTOMAware(javax.xml.stream.XMLStreamReader reader) {
-        boolean isReaderMTOMAware = false;
-        
-        try{
-          isReaderMTOMAware = java.lang.Boolean.TRUE.equals(reader.getProperty(org.apache.axiom.om.OMConstants.IS_DATA_HANDLERS_AWARE));
-        }catch(java.lang.IllegalArgumentException e){
-          isReaderMTOMAware = false;
-        }
-        return isReaderMTOMAware;
-   }
-     
-     
         /**
         *
         * @param parentQName
@@ -455,31 +439,7 @@
                 
                                     if (reader.isStartElement()  || reader.hasText()){
                                 
-                                    if (isReaderMTOMAware(reader)
-                                            &&
-                                            java.lang.Boolean.TRUE.equals(reader.getProperty(org.apache.axiom.om.OMConstants.IS_BINARY)))
-                                    {
-                                        //MTOM aware reader - get the datahandler directly and put it in the object
-                                        object.setBase64Binary(
-                                                (javax.activation.DataHandler) reader.getProperty(org.apache.axiom.om.OMConstants.DATA_HANDLER));
-                                    } else {
-                                        if (reader.getEventType() == javax.xml.stream.XMLStreamConstants.START_ELEMENT && reader.getName().equals(new javax.xml.namespace.QName(org.apache.axiom.om.impl.MTOMConstants.XOP_NAMESPACE_URI, org.apache.axiom.om.impl.MTOMConstants.XOP_INCLUDE)))
-                                        {
-                                            java.lang.String id = org.apache.axiom.om.util.ElementHelper.getContentID(reader, "UTF-8");
-                                            object.setBase64Binary(((org.apache.axiom.soap.impl.builder.MTOMStAXSOAPModelBuilder) ((org.apache.axiom.om.impl.llom.OMStAXWrapper) reader).getBuilder()).getDataHandler(id));
-                                            reader.next();
-                                            
-                                        } else if(reader.hasText()) {
-                                            //Do the usual conversion
-                                            java.lang.String content = reader.getText();
-                                            object.setBase64Binary(
-                                                    org.apache.axis2.databinding.utils.ConverterUtil.convertToBase64Binary(content));
-                                            
-                                        }
-                                    }
-
-                                      
-                                        reader.next();
+                                        object.setBase64Binary(org.apache.axiom.util.stax.XMLStreamReaderUtils.getDataHandlerFromElement(reader));
                                     
                               }  // End of if for expected property start element
                                 
diff --git a/modules/adb/src/org/apache/axis2/databinding/types/xsd/Base64Binary.java b/modules/adb/src/org/apache/axis2/databinding/types/xsd/Base64Binary.java
index 2ba0cd7..15fb552 100644
--- a/modules/adb/src/org/apache/axis2/databinding/types/xsd/Base64Binary.java
+++ b/modules/adb/src/org/apache/axis2/databinding/types/xsd/Base64Binary.java
@@ -455,31 +455,7 @@
                 
                                     if (reader.isStartElement()  || reader.hasText()){
                                 
-                                    if (isReaderMTOMAware(reader)
-                                            &&
-                                            java.lang.Boolean.TRUE.equals(reader.getProperty(org.apache.axiom.om.OMConstants.IS_BINARY)))
-                                    {
-                                        //MTOM aware reader - get the datahandler directly and put it in the object
-                                        object.setBase64Binary(
-                                                (javax.activation.DataHandler) reader.getProperty(org.apache.axiom.om.OMConstants.DATA_HANDLER));
-                                    } else {
-                                        if (reader.getEventType() == javax.xml.stream.XMLStreamConstants.START_ELEMENT && reader.getName().equals(new javax.xml.namespace.QName(org.apache.axiom.om.impl.MTOMConstants.XOP_NAMESPACE_URI, org.apache.axiom.om.impl.MTOMConstants.XOP_INCLUDE)))
-                                        {
-                                            java.lang.String id = org.apache.axiom.om.util.ElementHelper.getContentID(reader, "UTF-8");
-                                            object.setBase64Binary(((org.apache.axiom.soap.impl.builder.MTOMStAXSOAPModelBuilder) ((org.apache.axiom.om.impl.llom.OMStAXWrapper) reader).getBuilder()).getDataHandler(id));
-                                            reader.next();
-                                            
-                                        } else if(reader.hasText()) {
-                                            //Do the usual conversion
-                                            java.lang.String content = reader.getText();
-                                            object.setBase64Binary(
-                                                    org.apache.axis2.databinding.utils.ConverterUtil.convertToBase64Binary(content));
-                                            
-                                        }
-                                    }
-
-                                      
-                                        reader.next();
+                                        object.setBase64Binary(org.apache.axiom.util.stax.XMLStreamReaderUtils.getDataHandlerFromElement(reader));
                                     
                               }  // End of if for expected property start element
                                 
diff --git a/modules/adb/src/org/apache/axis2/databinding/utils/ConverterUtil.java b/modules/adb/src/org/apache/axis2/databinding/utils/ConverterUtil.java
index 8547210..ad98668 100644
--- a/modules/adb/src/org/apache/axis2/databinding/utils/ConverterUtil.java
+++ b/modules/adb/src/org/apache/axis2/databinding/utils/ConverterUtil.java
@@ -22,15 +22,11 @@ package org.apache.axis2.databinding.utils;
 import org.apache.axiom.attachments.ByteArrayDataSource;
 import org.apache.axiom.attachments.utils.IOUtils;
 import org.apache.axiom.om.OMAbstractFactory;
-import org.apache.axiom.om.OMConstants;
 import org.apache.axiom.om.OMElement;
-import org.apache.axiom.om.impl.MTOMConstants;
 import org.apache.axiom.om.impl.builder.StAXOMBuilder;
-import org.apache.axiom.om.impl.llom.OMStAXWrapper;
 import org.apache.axiom.om.util.Base64;
-import org.apache.axiom.om.util.ElementHelper;
 import org.apache.axiom.om.util.StAXUtils;
-import org.apache.axiom.soap.impl.builder.MTOMStAXSOAPModelBuilder;
+import org.apache.axiom.util.stax.XMLStreamReaderUtils;
 import org.apache.axis2.databinding.ADBBean;
 import org.apache.axis2.databinding.ADBException;
 import org.apache.axis2.databinding.i18n.ADBMessages;
@@ -1525,8 +1521,7 @@ public class ConverterUtil {
 
                 if (Constants.XSD_NAMESPACE.equals(attributeNameSpace)) {
                     if ("base64Binary".equals(attributeType)) {
-                        xmlStreamReader.next();
-                        returnObject = getDataHandlerObject(xmlStreamReader);
+                        returnObject = XMLStreamReaderUtils.getDataHandlerFromElement(xmlStreamReader);
                     } else {
                         String attribValue = xmlStreamReader.getElementText();
                         if (attribValue != null) {
@@ -1617,26 +1612,6 @@ public class ConverterUtil {
         return returnObject;
     }
 
-    private static Object getDataHandlerObject(XMLStreamReader reader) throws XMLStreamException {
-        Object dataHandler = null;
-        if (Boolean.TRUE.equals(reader.getProperty(OMConstants.IS_DATA_HANDLERS_AWARE))
-                && Boolean.TRUE.equals(reader.getProperty(OMConstants.IS_BINARY))) {
-            dataHandler = reader.getProperty(org.apache.axiom.om.OMConstants.DATA_HANDLER);
-        } else {
-            if (reader.getEventType() == XMLStreamConstants.START_ELEMENT &&
-                    reader.getName().equals(new QName(MTOMConstants.XOP_NAMESPACE_URI, MTOMConstants.XOP_INCLUDE))) {
-                String id = ElementHelper.getContentID(reader, "UTF-8");
-                dataHandler = ((MTOMStAXSOAPModelBuilder) ((OMStAXWrapper) reader).getBuilder()).getDataHandler(id);
-                reader.next();
-            } else if (reader.hasText()) {
-                String content = reader.getText();
-                dataHandler = ConverterUtil.convertToBase64Binary(content);
-
-            }
-        }
-        return dataHandler;
-    }
-
     static {
         isCustomClassPresent = (System.getProperty(SYSTEM_PROPERTY_ADB_CONVERTERUTIL) != null);
         if (isCustomClassPresent){


[axis-axis2-java-core] 18/38: Merged r1242249 to the 1.5 branch.

Posted by bi...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

billblough pushed a commit to branch 1_5
in repository https://gitbox.apache.org/repos/asf/axis-axis2-java-core.git

commit 950a1d870a7f9731a43520a35d3cbb3393349ed0
Author: Sagara Gunathunga <sa...@apache.org>
AuthorDate: Thu Feb 9 09:24:01 2012 +0000

    Merged r1242249 to the 1.5 branch.
---
 .../src/main/java/org/apache/axis2/maven2/java2wsdl/Java2WSDLMojo.java  | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)

diff --git a/modules/tool/axis2-java2wsdl-maven-plugin/src/main/java/org/apache/axis2/maven2/java2wsdl/Java2WSDLMojo.java b/modules/tool/axis2-java2wsdl-maven-plugin/src/main/java/org/apache/axis2/maven2/java2wsdl/Java2WSDLMojo.java
index 7bf632e..c198eb7 100644
--- a/modules/tool/axis2-java2wsdl-maven-plugin/src/main/java/org/apache/axis2/maven2/java2wsdl/Java2WSDLMojo.java
+++ b/modules/tool/axis2-java2wsdl-maven-plugin/src/main/java/org/apache/axis2/maven2/java2wsdl/Java2WSDLMojo.java
@@ -128,7 +128,7 @@ public class Java2WSDLMojo extends AbstractMojo {
 
     /**
      * Schema Generator
-     * @parameter expression="${axis2.java2wsdl.nsGenClassName}"
+     * @parameter expression="${axis2.java2wsdl.schemaGenClassName}"
      */
     private String schemaGenClassName;
 


[axis-axis2-java-core] 24/38: Merged r1299392 to the 1.5 branch to avoid hanging builds.

Posted by bi...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

billblough pushed a commit to branch 1_5
in repository https://gitbox.apache.org/repos/asf/axis-axis2-java-core.git

commit d113d79f55ccde75e87455e3dde11ae3ec0a5c3b
Author: Andreas Veithen <ve...@apache.org>
AuthorDate: Sun Mar 11 18:50:06 2012 +0000

    Merged r1299392 to the 1.5 branch to avoid hanging builds.
---
 .../axis2/transport/http/server/DefaultConnectionListener.java      | 6 +++---
 .../org/apache/axis2/transport/http/server/SimpleHttpServer.java    | 4 +++-
 2 files changed, 6 insertions(+), 4 deletions(-)

diff --git a/modules/transport/http/src/org/apache/axis2/transport/http/server/DefaultConnectionListener.java b/modules/transport/http/src/org/apache/axis2/transport/http/server/DefaultConnectionListener.java
index 2c39991..da095b2 100644
--- a/modules/transport/http/src/org/apache/axis2/transport/http/server/DefaultConnectionListener.java
+++ b/modules/transport/http/src/org/apache/axis2/transport/http/server/DefaultConnectionListener.java
@@ -106,7 +106,7 @@ public class DefaultConnectionListener implements IOProcessor {
     }
 
     public synchronized void awaitSocketOpen() throws InterruptedException {
-        while (serversocket == null) {
+        while (serversocket == null && !destroyed) {
             wait();
         }
     }
@@ -122,7 +122,7 @@ public class DefaultConnectionListener implements IOProcessor {
         }
     }
 
-    public void destroy() {
+    public synchronized void destroy() {
         this.destroyed = true;
         try {
             close();
@@ -133,7 +133,7 @@ public class DefaultConnectionListener implements IOProcessor {
         }
     }
 
-    public boolean isDestroyed() {
+    public synchronized boolean isDestroyed() {
         return this.destroyed;
     }
 
diff --git a/modules/transport/http/src/org/apache/axis2/transport/http/server/SimpleHttpServer.java b/modules/transport/http/src/org/apache/axis2/transport/http/server/SimpleHttpServer.java
index 7debb56..0ad04c3 100644
--- a/modules/transport/http/src/org/apache/axis2/transport/http/server/SimpleHttpServer.java
+++ b/modules/transport/http/src/org/apache/axis2/transport/http/server/SimpleHttpServer.java
@@ -100,7 +100,9 @@ public class SimpleHttpServer {
         this.listenerExecutor.execute(listener);
         try {
             listener.awaitSocketOpen();
-            port = listener.getPort();
+            if (!listener.isDestroyed()) {
+                port = listener.getPort();
+            }
         } catch (InterruptedException ex) {
             Thread.currentThread().interrupt();
         }


[axis-axis2-java-core] 01/38: [maven-release-plugin] prepare for next development iteration

Posted by bi...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

billblough pushed a commit to branch 1_5
in repository https://gitbox.apache.org/repos/asf/axis-axis2-java-core.git

commit 0a3414863cda35c08daf511a744d77925c8d13fe
Author: Andreas Veithen <ve...@apache.org>
AuthorDate: Tue Aug 30 19:54:27 2011 +0000

    [maven-release-plugin] prepare for next development iteration
---
 modules/adb-codegen/pom.xml                       |  8 ++++----
 modules/adb/pom.xml                               |  8 ++++----
 modules/addressing/pom.xml                        |  8 ++++----
 modules/clustering/pom.xml                        |  8 ++++----
 modules/codegen/pom.xml                           |  8 ++++----
 modules/corba/pom.xml                             |  8 ++++----
 modules/distribution/pom.xml                      |  8 ++++----
 modules/fastinfoset/pom.xml                       |  8 ++++----
 modules/integration/pom.xml                       |  8 ++++----
 modules/java2wsdl/pom.xml                         |  8 ++++----
 modules/jaxbri/pom.xml                            |  8 ++++----
 modules/jaxws-integration/pom.xml                 |  8 ++++----
 modules/jaxws-mar/pom.xml                         |  8 ++++----
 modules/jaxws/pom.xml                             |  8 ++++----
 modules/jibx/pom.xml                              |  8 ++++----
 modules/json/pom.xml                              |  8 ++++----
 modules/kernel/pom.xml                            |  8 ++++----
 modules/metadata/pom.xml                          |  8 ++++----
 modules/mex/pom.xml                               |  8 ++++----
 modules/mtompolicy-mar/pom.xml                    |  8 ++++----
 modules/mtompolicy/pom.xml                        |  8 ++++----
 modules/osgi/pom.xml                              |  8 ++++----
 modules/parent/pom.xml                            |  8 ++++----
 modules/ping/pom.xml                              |  8 ++++----
 modules/resource-bundle/pom.xml                   |  8 ++++----
 modules/saaj/pom.xml                              |  8 ++++----
 modules/samples/java_first_jaxws/pom.xml          | 10 +++++-----
 modules/samples/jaxws-addressbook/pom.xml         |  4 ++--
 modules/samples/jaxws-calculator/pom.xml          |  4 ++--
 modules/samples/jaxws-interop/pom.xml             |  4 ++--
 modules/samples/jaxws-samples/pom.xml             | 12 ++++++------
 modules/samples/jaxws-version/pom.xml             |  2 +-
 modules/samples/version/pom.xml                   |  8 ++++----
 modules/scripting/pom.xml                         |  8 ++++----
 modules/soapmonitor/module/pom.xml                |  8 ++++----
 modules/soapmonitor/servlet/pom.xml               |  8 ++++----
 modules/spring/pom.xml                            |  8 ++++----
 modules/testutils/pom.xml                         |  8 ++++----
 modules/tool/axis2-aar-maven-plugin/pom.xml       |  8 ++++----
 modules/tool/axis2-ant-plugin/pom.xml             |  8 ++++----
 modules/tool/axis2-eclipse-codegen-plugin/pom.xml |  8 ++++----
 modules/tool/axis2-eclipse-service-plugin/pom.xml |  8 ++++----
 modules/tool/axis2-idea-plugin/pom.xml            |  8 ++++----
 modules/tool/axis2-java2wsdl-maven-plugin/pom.xml |  8 ++++----
 modules/tool/axis2-mar-maven-plugin/pom.xml       |  8 ++++----
 modules/tool/axis2-repo-maven-plugin/pom.xml      |  8 ++++----
 modules/tool/axis2-wsdl2code-maven-plugin/pom.xml |  8 ++++----
 modules/transport/http/pom.xml                    |  8 ++++----
 modules/transport/local/pom.xml                   |  8 ++++----
 modules/webapp/pom.xml                            |  8 ++++----
 modules/xmlbeans/pom.xml                          |  8 ++++----
 pom.xml                                           |  8 ++++----
 52 files changed, 202 insertions(+), 202 deletions(-)

diff --git a/modules/adb-codegen/pom.xml b/modules/adb-codegen/pom.xml
index 44793e9..2a3ffea 100644
--- a/modules/adb-codegen/pom.xml
+++ b/modules/adb-codegen/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.axis2</groupId>
         <artifactId>axis2-parent</artifactId>
-        <version>1.5.6</version>
+        <version>1.5.7-SNAPSHOT</version>
         <relativePath>../parent/pom.xml</relativePath>
     </parent>
     <artifactId>axis2-adb-codegen</artifactId>
@@ -58,9 +58,9 @@
     </dependencies>
     <url>http://axis.apache.org/axis2/java/core/</url>
     <scm>
-        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6/modules/adb-codegen</connection>
-        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6/modules/adb-codegen</developerConnection>
-        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/tags/v1.5.6/modules/adb-codegen</url>
+        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5/modules/adb-codegen</connection>
+        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5/modules/adb-codegen</developerConnection>
+        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/branches/1_5/modules/adb-codegen</url>
     </scm>
     <build>
         <sourceDirectory>src</sourceDirectory>
diff --git a/modules/adb/pom.xml b/modules/adb/pom.xml
index 1956314..8ddd15f 100644
--- a/modules/adb/pom.xml
+++ b/modules/adb/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.axis2</groupId>
         <artifactId>axis2-parent</artifactId>
-        <version>1.5.6</version>
+        <version>1.5.7-SNAPSHOT</version>
         <relativePath>../parent/pom.xml</relativePath>
     </parent>
 
@@ -33,9 +33,9 @@
     <description>Axis2 Data Binding module</description>
     <url>http://axis.apache.org/axis2/java/core/</url>
     <scm>
-        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6/modules/adb</connection>
-        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6/modules/adb</developerConnection>
-        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/tags/v1.5.6/modules/adb</url>
+        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5/modules/adb</connection>
+        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5/modules/adb</developerConnection>
+        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/branches/1_5/modules/adb</url>
     </scm>
     <dependencies>
         <dependency>
diff --git a/modules/addressing/pom.xml b/modules/addressing/pom.xml
index afc1e78..02f187b 100644
--- a/modules/addressing/pom.xml
+++ b/modules/addressing/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.axis2</groupId>
         <artifactId>axis2-parent</artifactId>
-        <version>1.5.6</version>
+        <version>1.5.7-SNAPSHOT</version>
         <relativePath>../parent/pom.xml</relativePath>
     </parent>
     <artifactId>addressing</artifactId>
@@ -45,9 +45,9 @@
     </dependencies>
     <url>http://axis.apache.org/axis2/java/core/</url>
     <scm>
-        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6/modules/addressing</connection>
-        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6/modules/addressing</developerConnection>
-        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/tags/v1.5.6/modules/addressing</url>
+        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5/modules/addressing</connection>
+        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5/modules/addressing</developerConnection>
+        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/branches/1_5/modules/addressing</url>
     </scm>
     <build>
         <sourceDirectory>src</sourceDirectory>
diff --git a/modules/clustering/pom.xml b/modules/clustering/pom.xml
index aeea46f..0919047 100644
--- a/modules/clustering/pom.xml
+++ b/modules/clustering/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.axis2</groupId>
         <artifactId>axis2-parent</artifactId>
-        <version>1.5.6</version>
+        <version>1.5.7-SNAPSHOT</version>
         <relativePath>../parent/pom.xml</relativePath>
     </parent>
     <artifactId>axis2-clustering</artifactId>
@@ -59,9 +59,9 @@
     </dependencies>
     <url>http://axis.apache.org/axis2/java/core/</url>
     <scm>
-        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6/modules/clustering</connection>
-        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6/modules/clustering</developerConnection>
-        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/tags/v1.5.6/modules/clustering</url>
+        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5/modules/clustering</connection>
+        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5/modules/clustering</developerConnection>
+        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/branches/1_5/modules/clustering</url>
     </scm>
     <build>
         <sourceDirectory>src</sourceDirectory>
diff --git a/modules/codegen/pom.xml b/modules/codegen/pom.xml
index 02970bb..1b55401 100644
--- a/modules/codegen/pom.xml
+++ b/modules/codegen/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.axis2</groupId>
         <artifactId>axis2-parent</artifactId>
-        <version>1.5.6</version>
+        <version>1.5.7-SNAPSHOT</version>
         <relativePath>../parent/pom.xml</relativePath>
     </parent>
     <artifactId>axis2-codegen</artifactId>
@@ -56,9 +56,9 @@
     </dependencies>
     <url>http://axis.apache.org/axis2/java/core/</url>
     <scm>
-        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6/modules/codegen</connection>
-        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6/modules/codegen</developerConnection>
-        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/tags/v1.5.6/modules/codegen</url>
+        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5/modules/codegen</connection>
+        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5/modules/codegen</developerConnection>
+        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/branches/1_5/modules/codegen</url>
     </scm>
     <build>
         <sourceDirectory>src</sourceDirectory>
diff --git a/modules/corba/pom.xml b/modules/corba/pom.xml
index 0b62d0e..820c7d0 100644
--- a/modules/corba/pom.xml
+++ b/modules/corba/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.axis2</groupId>
         <artifactId>axis2-parent</artifactId>
-        <version>1.5.6</version>
+        <version>1.5.7-SNAPSHOT</version>
         <relativePath>../parent/pom.xml</relativePath>
     </parent>
     <artifactId>axis2-corba</artifactId>
@@ -58,9 +58,9 @@
     </dependencies>
     <url>http://axis.apache.org/axis2/java/core/</url>
     <scm>
-        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6/modules/corba</connection>
-        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6/modules/corba</developerConnection>
-        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/tags/v1.5.6/modules/corba</url>
+        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5/modules/corba</connection>
+        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5/modules/corba</developerConnection>
+        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/branches/1_5/modules/corba</url>
     </scm>
     <build>
         <sourceDirectory>src</sourceDirectory>
diff --git a/modules/distribution/pom.xml b/modules/distribution/pom.xml
index 0d9bad8..f30deb6 100755
--- a/modules/distribution/pom.xml
+++ b/modules/distribution/pom.xml
@@ -22,7 +22,7 @@
     <parent>
         <groupId>org.apache.axis2</groupId>
         <artifactId>axis2-parent</artifactId>
-        <version>1.5.6</version>
+        <version>1.5.7-SNAPSHOT</version>
         <relativePath>../parent/pom.xml</relativePath>
     </parent>
 
@@ -231,9 +231,9 @@
     </dependencies>
     <url>http://axis.apache.org/axis2/java/core/</url>
     <scm>
-        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6/modules/distribution</connection>
-        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6/modules/distribution</developerConnection>
-        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/tags/v1.5.6/modules/distribution</url>
+        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5/modules/distribution</connection>
+        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5/modules/distribution</developerConnection>
+        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/branches/1_5/modules/distribution</url>
     </scm>
     <build>
         <plugins>
diff --git a/modules/fastinfoset/pom.xml b/modules/fastinfoset/pom.xml
index acc7f2c..bda7428 100644
--- a/modules/fastinfoset/pom.xml
+++ b/modules/fastinfoset/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.axis2</groupId>
         <artifactId>axis2-parent</artifactId>
-        <version>1.5.6</version>
+        <version>1.5.7-SNAPSHOT</version>
         <relativePath>../parent/pom.xml</relativePath>
     </parent>
     <artifactId>axis2-fastinfoset</artifactId>
@@ -107,9 +107,9 @@
     </dependencies>
     <url>http://axis.apache.org/axis2/java/core/</url>
     <scm>
-        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6/modules/fastinfoset</connection>
-        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6/modules/fastinfoset</developerConnection>
-        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/tags/v1.5.6/modules/fastinfoset</url>
+        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5/modules/fastinfoset</connection>
+        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5/modules/fastinfoset</developerConnection>
+        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/branches/1_5/modules/fastinfoset</url>
     </scm>
     <build>
         <sourceDirectory>src</sourceDirectory>
diff --git a/modules/integration/pom.xml b/modules/integration/pom.xml
index 37190f0..f7d599f 100644
--- a/modules/integration/pom.xml
+++ b/modules/integration/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.axis2</groupId>
         <artifactId>axis2-parent</artifactId>
-        <version>1.5.6</version>
+        <version>1.5.7-SNAPSHOT</version>
         <relativePath>../parent/pom.xml</relativePath>
     </parent>
     <artifactId>axis2-integration</artifactId>
@@ -280,9 +280,9 @@
     </profiles>
     <url>http://axis.apache.org/axis2/java/core/</url>
     <scm>
-        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6/modules/integration</connection>
-        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6/modules/integration</developerConnection>
-        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/tags/v1.5.6/modules/integration</url>
+        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5/modules/integration</connection>
+        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5/modules/integration</developerConnection>
+        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/branches/1_5/modules/integration</url>
     </scm>
     <build>
         <sourceDirectory>src</sourceDirectory>
diff --git a/modules/java2wsdl/pom.xml b/modules/java2wsdl/pom.xml
index 3a34c85..80b50b9 100644
--- a/modules/java2wsdl/pom.xml
+++ b/modules/java2wsdl/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.axis2</groupId>
         <artifactId>axis2-parent</artifactId>
-        <version>1.5.6</version>
+        <version>1.5.7-SNAPSHOT</version>
         <relativePath>../parent/pom.xml</relativePath>
     </parent>
     <artifactId>axis2-java2wsdl</artifactId>
@@ -73,9 +73,9 @@
     </dependencies>
     <url>http://axis.apache.org/axis2/java/core/</url>
     <scm>
-        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6/modules/java2wsdl</connection>
-        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6/modules/java2wsdl</developerConnection>
-        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/tags/v1.5.6/modules/java2wsdl</url>
+        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5/modules/java2wsdl</connection>
+        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5/modules/java2wsdl</developerConnection>
+        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/branches/1_5/modules/java2wsdl</url>
     </scm>
     <build>
         <sourceDirectory>src</sourceDirectory>
diff --git a/modules/jaxbri/pom.xml b/modules/jaxbri/pom.xml
index fa0393f..31ec9b4 100644
--- a/modules/jaxbri/pom.xml
+++ b/modules/jaxbri/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.axis2</groupId>
         <artifactId>axis2-parent</artifactId>
-        <version>1.5.6</version>
+        <version>1.5.7-SNAPSHOT</version>
         <relativePath>../parent/pom.xml</relativePath>
     </parent>
     <artifactId>axis2-jaxbri</artifactId>
@@ -66,9 +66,9 @@
     </dependencies>
     <url>http://axis.apache.org/axis2/java/core/</url>
     <scm>
-        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6/modules/jaxbri</connection>
-        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6/modules/jaxbri</developerConnection>
-        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/tags/v1.5.6/modules/jaxbri</url>
+        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5/modules/jaxbri</connection>
+        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5/modules/jaxbri</developerConnection>
+        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/branches/1_5/modules/jaxbri</url>
     </scm>
     <build>
         <sourceDirectory>src</sourceDirectory>
diff --git a/modules/jaxws-integration/pom.xml b/modules/jaxws-integration/pom.xml
index a52112b..1f34d6e 100644
--- a/modules/jaxws-integration/pom.xml
+++ b/modules/jaxws-integration/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.axis2</groupId>
         <artifactId>axis2-parent</artifactId>
-        <version>1.5.6</version>
+        <version>1.5.7-SNAPSHOT</version>
         <relativePath>../parent/pom.xml</relativePath>
     </parent>
     <artifactId>axis2-jaxws-integration</artifactId>
@@ -90,9 +90,9 @@
     </dependencies>
     <url>http://axis.apache.org/axis2/java/core/</url>
     <scm>
-        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6/modules/jaxws-integration</connection>
-        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6/modules/jaxws-integration</developerConnection>
-        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/tags/v1.5.6/modules/jaxws-integration</url>
+        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5/modules/jaxws-integration</connection>
+        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5/modules/jaxws-integration</developerConnection>
+        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/branches/1_5/modules/jaxws-integration</url>
     </scm>
     <build>
         <sourceDirectory>src</sourceDirectory>
diff --git a/modules/jaxws-mar/pom.xml b/modules/jaxws-mar/pom.xml
index bbf738c..d71515c 100644
--- a/modules/jaxws-mar/pom.xml
+++ b/modules/jaxws-mar/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.axis2</groupId>
         <artifactId>axis2-parent</artifactId>
-        <version>1.5.6</version>
+        <version>1.5.7-SNAPSHOT</version>
         <relativePath>../parent/pom.xml</relativePath>
     </parent>
     <artifactId>axis2-jaxws-mar</artifactId>
@@ -42,9 +42,9 @@
 
     <url>http://axis.apache.org/axis2/java/core/</url>
     <scm>
-        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6/modules/jaxws-mar</connection>
-        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6/modules/jaxws-mar</developerConnection>
-        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/tags/v1.5.6/modules/jaxws-mar</url>
+        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5/modules/jaxws-mar</connection>
+        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5/modules/jaxws-mar</developerConnection>
+        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/branches/1_5/modules/jaxws-mar</url>
     </scm>
     
     <build>
diff --git a/modules/jaxws/pom.xml b/modules/jaxws/pom.xml
index d266292..097e638 100644
--- a/modules/jaxws/pom.xml
+++ b/modules/jaxws/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.axis2</groupId>
         <artifactId>axis2-parent</artifactId>
-        <version>1.5.6</version>
+        <version>1.5.7-SNAPSHOT</version>
         <relativePath>../parent/pom.xml</relativePath>
     </parent>
     <artifactId>axis2-jaxws</artifactId>
@@ -110,9 +110,9 @@
     </dependencies>
     <url>http://axis.apache.org/axis2/java/core/</url>
     <scm>
-        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6/modules/jaxws</connection>
-        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6/modules/jaxws</developerConnection>
-        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/tags/v1.5.6/modules/jaxws</url>
+        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5/modules/jaxws</connection>
+        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5/modules/jaxws</developerConnection>
+        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/branches/1_5/modules/jaxws</url>
     </scm>
     <build>
         <sourceDirectory>src</sourceDirectory>
diff --git a/modules/jibx/pom.xml b/modules/jibx/pom.xml
index 25d16cc..91dfb3e 100644
--- a/modules/jibx/pom.xml
+++ b/modules/jibx/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.axis2</groupId>
         <artifactId>axis2-parent</artifactId>
-        <version>1.5.6</version>
+        <version>1.5.7-SNAPSHOT</version>
         <relativePath>../parent/pom.xml</relativePath>
     </parent>
     <artifactId>axis2-jibx</artifactId>
@@ -69,9 +69,9 @@
     </dependencies>
     <url>http://axis.apache.org/axis2/java/core/</url>
     <scm>
-        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6/modules/jibx</connection>
-        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6/modules/jibx</developerConnection>
-        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/tags/v1.5.6/modules/jibx</url>
+        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5/modules/jibx</connection>
+        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5/modules/jibx</developerConnection>
+        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/branches/1_5/modules/jibx</url>
     </scm>
     <build>
         <resources>
diff --git a/modules/json/pom.xml b/modules/json/pom.xml
index 0ea60ce..5e1feb4 100644
--- a/modules/json/pom.xml
+++ b/modules/json/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.axis2</groupId>
         <artifactId>axis2-parent</artifactId>
-        <version>1.5.6</version>
+        <version>1.5.7-SNAPSHOT</version>
         <relativePath>../parent/pom.xml</relativePath>
     </parent>
     <artifactId>axis2-json</artifactId>
@@ -58,9 +58,9 @@
     </dependencies>
     <url>http://axis.apache.org/axis2/java/core/</url>
     <scm>
-        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6/modules/json</connection>
-        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6/modules/json</developerConnection>
-        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/tags/v1.5.6/modules/json</url>
+        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5/modules/json</connection>
+        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5/modules/json</developerConnection>
+        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/branches/1_5/modules/json</url>
     </scm>
     <build>
         <sourceDirectory>src</sourceDirectory>
diff --git a/modules/kernel/pom.xml b/modules/kernel/pom.xml
index 20fe65a..0e607bb 100644
--- a/modules/kernel/pom.xml
+++ b/modules/kernel/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.axis2</groupId>
         <artifactId>axis2-parent</artifactId>
-        <version>1.5.6</version>
+        <version>1.5.7-SNAPSHOT</version>
         <relativePath>../parent/pom.xml</relativePath>
     </parent>
     <artifactId>axis2-kernel</artifactId>
@@ -98,9 +98,9 @@
     </dependencies>
     <url>http://axis.apache.org/axis2/java/core/</url>
     <scm>
-        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6/modules/kernel</connection>
-        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6/modules/kernel</developerConnection>
-        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/tags/v1.5.6/modules/kernel</url>
+        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5/modules/kernel</connection>
+        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5/modules/kernel</developerConnection>
+        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/branches/1_5/modules/kernel</url>
     </scm>
     <build>
         <sourceDirectory>src</sourceDirectory>
diff --git a/modules/metadata/pom.xml b/modules/metadata/pom.xml
index e487a2e..d6d8a9a 100755
--- a/modules/metadata/pom.xml
+++ b/modules/metadata/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.axis2</groupId>
         <artifactId>axis2-parent</artifactId>
-        <version>1.5.6</version>
+        <version>1.5.7-SNAPSHOT</version>
         <relativePath>../parent/pom.xml</relativePath>
     </parent>
     <artifactId>axis2-metadata</artifactId>
@@ -100,9 +100,9 @@
     </dependencies>
     <url>http://axis.apache.org/axis2/java/core/</url>
     <scm>
-        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6/modules/metadata</connection>
-        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6/modules/metadata</developerConnection>
-        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/tags/v1.5.6/modules/metadata</url>
+        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5/modules/metadata</connection>
+        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5/modules/metadata</developerConnection>
+        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/branches/1_5/modules/metadata</url>
     </scm>
     <build>
         <sourceDirectory>src</sourceDirectory>
diff --git a/modules/mex/pom.xml b/modules/mex/pom.xml
index 06bcbe7..edc14f3 100644
--- a/modules/mex/pom.xml
+++ b/modules/mex/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.axis2</groupId>
         <artifactId>axis2-parent</artifactId>
-        <version>1.5.6</version>
+        <version>1.5.7-SNAPSHOT</version>
         <relativePath>../parent/pom.xml</relativePath>
     </parent>
     <artifactId>mex</artifactId>
@@ -40,9 +40,9 @@
     </dependencies>
     <url>http://axis.apache.org/axis2/java/core/</url>
     <scm>
-        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6/modules/mex</connection>
-        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6/modules/mex</developerConnection>
-        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/tags/v1.5.6/modules/mex</url>
+        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5/modules/mex</connection>
+        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5/modules/mex</developerConnection>
+        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/branches/1_5/modules/mex</url>
     </scm>
     <build>
         <sourceDirectory>src</sourceDirectory>
diff --git a/modules/mtompolicy-mar/pom.xml b/modules/mtompolicy-mar/pom.xml
index 66d265a..92e76b4 100644
--- a/modules/mtompolicy-mar/pom.xml
+++ b/modules/mtompolicy-mar/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.axis2</groupId>
         <artifactId>axis2-parent</artifactId>
-        <version>1.5.6</version>
+        <version>1.5.7-SNAPSHOT</version>
         <relativePath>../parent/pom.xml</relativePath>
     </parent>
     <artifactId>mtompolicy</artifactId>
@@ -49,9 +49,9 @@
     </dependencies>
     <url>http://axis.apache.org/axis2/java/core/</url>
     <scm>
-        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6/modules/mtompolicy-mar</connection>
-        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6/modules/mtompolicy-mar</developerConnection>
-        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/tags/v1.5.6/modules/mtompolicy-mar</url>
+        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5/modules/mtompolicy-mar</connection>
+        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5/modules/mtompolicy-mar</developerConnection>
+        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/branches/1_5/modules/mtompolicy-mar</url>
     </scm>
     <build>
         <sourceDirectory>src</sourceDirectory>
diff --git a/modules/mtompolicy/pom.xml b/modules/mtompolicy/pom.xml
index 2c0e260..186d140 100644
--- a/modules/mtompolicy/pom.xml
+++ b/modules/mtompolicy/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.axis2</groupId>
         <artifactId>axis2-parent</artifactId>
-        <version>1.5.6</version>
+        <version>1.5.7-SNAPSHOT</version>
         <relativePath>../parent/pom.xml</relativePath>
     </parent>
     <artifactId>axis2-mtompolicy</artifactId>
@@ -43,9 +43,9 @@
     </dependencies>
     <url>http://axis.apache.org/axis2/java/core/</url>
     <scm>
-        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6/modules/mtompolicy</connection>
-        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6/modules/mtompolicy</developerConnection>
-        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/tags/v1.5.6/modules/mtompolicy</url>
+        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5/modules/mtompolicy</connection>
+        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5/modules/mtompolicy</developerConnection>
+        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/branches/1_5/modules/mtompolicy</url>
     </scm>
     <build>
         <sourceDirectory>src</sourceDirectory>
diff --git a/modules/osgi/pom.xml b/modules/osgi/pom.xml
index e27ad7f..fe62a05 100644
--- a/modules/osgi/pom.xml
+++ b/modules/osgi/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.axis2</groupId>
         <artifactId>axis2-parent</artifactId>
-        <version>1.5.6</version>
+        <version>1.5.7-SNAPSHOT</version>
         <relativePath>../parent/pom.xml</relativePath>
     </parent>
 
@@ -35,9 +35,9 @@
     <description>Apache Axis2 OSGi Integration</description>
     <url>http://axis.apache.org/axis2/java/core/</url>
     <scm>
-        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6/modules/osgi</connection>
-        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6/modules/osgi</developerConnection>
-        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/tags/v1.5.6/modules/osgi</url>
+        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5/modules/osgi</connection>
+        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5/modules/osgi</developerConnection>
+        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/branches/1_5/modules/osgi</url>
     </scm>
     <build>
         <sourceDirectory>src</sourceDirectory>
diff --git a/modules/parent/pom.xml b/modules/parent/pom.xml
index d9139a3..5e467a2 100644
--- a/modules/parent/pom.xml
+++ b/modules/parent/pom.xml
@@ -28,7 +28,7 @@
     <modelVersion>4.0.0</modelVersion>
     <groupId>org.apache.axis2</groupId>
     <artifactId>axis2-parent</artifactId>
-    <version>1.5.6</version>
+    <version>1.5.7-SNAPSHOT</version>
     <packaging>pom</packaging>
     <name>Apache Axis2 - Parent</name>
     <inceptionYear>2004</inceptionYear>
@@ -970,9 +970,9 @@
         </profile>
     </profiles>
     <scm>
-        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6/modules/parent</connection>
-        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6/modules/parent</developerConnection>
-        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/tags/v1.5.6/modules/parent</url>
+        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5/modules/parent</connection>
+        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5/modules/parent</developerConnection>
+        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/branches/1_5/modules/parent</url>
     </scm>
     <build>
         <pluginManagement>
diff --git a/modules/ping/pom.xml b/modules/ping/pom.xml
index 05efa6a..dec1518 100644
--- a/modules/ping/pom.xml
+++ b/modules/ping/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.axis2</groupId>
         <artifactId>axis2-parent</artifactId>
-        <version>1.5.6</version>
+        <version>1.5.7-SNAPSHOT</version>
         <relativePath>../parent/pom.xml</relativePath>
     </parent>
     <artifactId>ping</artifactId>
@@ -40,9 +40,9 @@
     </dependencies>
     <url>http://axis.apache.org/axis2/java/core/</url>
     <scm>
-        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6/modules/ping</connection>
-        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6/modules/ping</developerConnection>
-        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/tags/v1.5.6/modules/ping</url>
+        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5/modules/ping</connection>
+        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5/modules/ping</developerConnection>
+        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/branches/1_5/modules/ping</url>
     </scm>
     <build>
         <sourceDirectory>src</sourceDirectory>
diff --git a/modules/resource-bundle/pom.xml b/modules/resource-bundle/pom.xml
index 7afcbf5..97af406 100644
--- a/modules/resource-bundle/pom.xml
+++ b/modules/resource-bundle/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.axis2</groupId>
         <artifactId>axis2-parent</artifactId>
-        <version>1.5.6</version>
+        <version>1.5.7-SNAPSHOT</version>
         <relativePath>../parent/pom.xml</relativePath>
     </parent>
     <artifactId>axis2-resource-bundle</artifactId>
@@ -32,9 +32,9 @@
     <description>Contains the legal files that must be included in all artifacts</description>
     <url>http://axis.apache.org/axis2/java/core/</url>
     <scm>
-        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6/modules/resource-bundle</connection>
-        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6/modules/resource-bundle</developerConnection>
-        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/tags/v1.5.6/modules/resource-bundle</url>
+        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5/modules/resource-bundle</connection>
+        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5/modules/resource-bundle</developerConnection>
+        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/branches/1_5/modules/resource-bundle</url>
     </scm>
     <build>
         <plugins>
diff --git a/modules/saaj/pom.xml b/modules/saaj/pom.xml
index 4bb568b..a658307 100644
--- a/modules/saaj/pom.xml
+++ b/modules/saaj/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.axis2</groupId>
         <artifactId>axis2-parent</artifactId>
-        <version>1.5.6</version>
+        <version>1.5.7-SNAPSHOT</version>
         <relativePath>../parent/pom.xml</relativePath>
     </parent>
     <artifactId>axis2-saaj</artifactId>
@@ -32,9 +32,9 @@
     <description>Axis2 SAAJ implementation</description>
     <url>http://axis.apache.org/axis2/java/core/</url>
     <scm>
-        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6/modules/saaj</connection>
-        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6/modules/saaj</developerConnection>
-        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/tags/v1.5.6/modules/saaj</url>
+        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5/modules/saaj</connection>
+        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5/modules/saaj</developerConnection>
+        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/branches/1_5/modules/saaj</url>
     </scm>
     <dependencies>
         <dependency>
diff --git a/modules/samples/java_first_jaxws/pom.xml b/modules/samples/java_first_jaxws/pom.xml
index e88ee21..1a862bd 100644
--- a/modules/samples/java_first_jaxws/pom.xml
+++ b/modules/samples/java_first_jaxws/pom.xml
@@ -22,7 +22,7 @@
     <groupId>org.apache.axis2.examples</groupId>
     <artifactId>java_first_jaxws</artifactId>
     <name>JAXWS - Starting from Java Example</name>
-    <version>1.5.6</version>
+    <version>1.5.7-SNAPSHOT</version>
     <packaging>war</packaging>
     <inceptionYear>2004</inceptionYear>
 
@@ -36,22 +36,22 @@
         <dependency>
             <groupId>org.apache.axis2</groupId>
             <artifactId>axis2-kernel</artifactId>
-            <version>1.5.6</version>
+            <version>1.5.7-SNAPSHOT</version>
         </dependency>
         <dependency>
             <groupId>org.apache.axis2</groupId>
             <artifactId>axis2-jaxws</artifactId>
-            <version>1.5.6</version>
+            <version>1.5.7-SNAPSHOT</version>
         </dependency>
         <dependency>
             <groupId>org.apache.axis2</groupId>
             <artifactId>axis2-codegen</artifactId>
-            <version>1.5.6</version>
+            <version>1.5.7-SNAPSHOT</version>
         </dependency>
         <dependency>
             <groupId>org.apache.axis2</groupId>
             <artifactId>axis2-adb</artifactId>
-            <version>1.5.6</version>
+            <version>1.5.7-SNAPSHOT</version>
         </dependency>
         <dependency>
             <groupId>com.sun.xml.ws</groupId>
diff --git a/modules/samples/jaxws-addressbook/pom.xml b/modules/samples/jaxws-addressbook/pom.xml
index 6c0f104..52286fa 100644
--- a/modules/samples/jaxws-addressbook/pom.xml
+++ b/modules/samples/jaxws-addressbook/pom.xml
@@ -22,7 +22,7 @@
     <groupId>org.apache.axis2.samples</groupId>
     <artifactId>jaxws-addressbook</artifactId>
     <packaging>jar</packaging>
-    <version>1.5.6</version>
+    <version>1.5.7-SNAPSHOT</version>
     <name>JAXWS Addressbook Service</name>
     <build>
         <sourceDirectory>src</sourceDirectory>
@@ -129,7 +129,7 @@
         <dependency>
             <groupId>org.apache.axis2</groupId>
             <artifactId>axis2-jaxws</artifactId>
-            <version>1.5.6</version>
+            <version>1.5.7-SNAPSHOT</version>
         </dependency>
     </dependencies>
     <repositories>
diff --git a/modules/samples/jaxws-calculator/pom.xml b/modules/samples/jaxws-calculator/pom.xml
index 59305dc..b2a02cb 100644
--- a/modules/samples/jaxws-calculator/pom.xml
+++ b/modules/samples/jaxws-calculator/pom.xml
@@ -22,7 +22,7 @@
     <groupId>org.apache.axis2.samples</groupId>
     <artifactId>jaxws-calculator</artifactId>
     <packaging>jar</packaging>
-    <version>1.5.6</version>
+    <version>1.5.7-SNAPSHOT</version>
     <name>JAXWS Calculator Service</name>
     <build>
         <sourceDirectory>src</sourceDirectory>
@@ -77,7 +77,7 @@
         <dependency>
             <groupId>org.apache.axis2</groupId>
             <artifactId>axis2-jaxws</artifactId>
-            <version>1.5.6</version>
+            <version>1.5.7-SNAPSHOT</version>
         </dependency>
     </dependencies>
     <repositories>
diff --git a/modules/samples/jaxws-interop/pom.xml b/modules/samples/jaxws-interop/pom.xml
index 51223aa..754cb03 100644
--- a/modules/samples/jaxws-interop/pom.xml
+++ b/modules/samples/jaxws-interop/pom.xml
@@ -22,7 +22,7 @@
     <groupId>org.apache.axis2.samples</groupId>
     <artifactId>jaxws-interop</artifactId>
     <packaging>jar</packaging>
-    <version>1.5.6</version>
+    <version>1.5.7-SNAPSHOT</version>
     <name>JAXWS Interop Sample</name>
     <build>
         <sourceDirectory>src</sourceDirectory>
@@ -58,7 +58,7 @@
         <dependency>
             <groupId>org.apache.axis2</groupId>
             <artifactId>axis2-jaxws</artifactId>
-            <version>1.5.6</version>
+            <version>1.5.7-SNAPSHOT</version>
         </dependency>
     </dependencies>
     <repositories>
diff --git a/modules/samples/jaxws-samples/pom.xml b/modules/samples/jaxws-samples/pom.xml
index 0e86aa6..5f06a2a 100644
--- a/modules/samples/jaxws-samples/pom.xml
+++ b/modules/samples/jaxws-samples/pom.xml
@@ -22,7 +22,7 @@
     <groupId>org.apache.axis2.examples</groupId>
     <artifactId>jaxws-samples</artifactId>
     <name>JAXWS Samples - Echo, Ping, MTOM</name>
-    <version>1.5.6</version>
+    <version>1.5.7-SNAPSHOT</version>
     <packaging>war</packaging>
     <dependencies>
         <dependency>
@@ -34,27 +34,27 @@
         <dependency>
             <groupId>org.apache.axis2</groupId>
             <artifactId>axis2-kernel</artifactId>
-            <version>1.5.6</version>
+            <version>1.5.7-SNAPSHOT</version>
         </dependency>
         <dependency>
             <groupId>org.apache.axis2</groupId>
             <artifactId>axis2-jaxws</artifactId>
-            <version>1.5.6</version>
+            <version>1.5.7-SNAPSHOT</version>
         </dependency>
         <dependency>
             <groupId>org.apache.axis2</groupId>
             <artifactId>axis2-codegen</artifactId>
-            <version>1.5.6</version>
+            <version>1.5.7-SNAPSHOT</version>
         </dependency>
         <dependency>
             <groupId>org.apache.axis2</groupId>
             <artifactId>axis2-adb</artifactId>
-            <version>1.5.6</version>
+            <version>1.5.7-SNAPSHOT</version>
         </dependency>
         <dependency>
             <groupId>org.apache.axis2</groupId>
             <artifactId>addressing</artifactId>
-            <version>1.5.6</version>
+            <version>1.5.7-SNAPSHOT</version>
             <type>mar</type>
         </dependency>
         <dependency>
diff --git a/modules/samples/jaxws-version/pom.xml b/modules/samples/jaxws-version/pom.xml
index c84ab88..36ab234 100644
--- a/modules/samples/jaxws-version/pom.xml
+++ b/modules/samples/jaxws-version/pom.xml
@@ -21,7 +21,7 @@
     <modelVersion>4.0.0</modelVersion>
     <groupId>org.apache.axis2.examples</groupId>      
     <artifactId>jaxws-version</artifactId>
-    <version>1.5.6</version>
+    <version>1.5.7-SNAPSHOT</version>
     <packaging>jar</packaging>
     <name>Apache Axis2 -JAXWS Version Service</name>
     <build>
diff --git a/modules/samples/version/pom.xml b/modules/samples/version/pom.xml
index 031c99f..aa2dc5f 100644
--- a/modules/samples/version/pom.xml
+++ b/modules/samples/version/pom.xml
@@ -22,7 +22,7 @@
     <parent>
         <groupId>org.apache.axis2</groupId>
         <artifactId>axis2-parent</artifactId>
-        <version>1.5.6</version>
+        <version>1.5.7-SNAPSHOT</version>
         <relativePath>../../parent/pom.xml</relativePath>
     </parent>
     <artifactId>version</artifactId>
@@ -30,9 +30,9 @@
     <name>Apache Axis2 - Version Service</name>
     <url>http://axis.apache.org/axis2/java/core/</url>
     <scm>
-        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6/modules/samples/version</connection>
-        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6/modules/samples/version</developerConnection>
-        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/tags/v1.5.6/modules/samples/version</url>
+        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5/modules/samples/version</connection>
+        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5/modules/samples/version</developerConnection>
+        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/branches/1_5/modules/samples/version</url>
     </scm>
     <build>
         <sourceDirectory>src</sourceDirectory>
diff --git a/modules/scripting/pom.xml b/modules/scripting/pom.xml
index c5e6326..a3d554f 100644
--- a/modules/scripting/pom.xml
+++ b/modules/scripting/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.axis2</groupId>
         <artifactId>axis2-parent</artifactId>
-        <version>1.5.6</version>
+        <version>1.5.7-SNAPSHOT</version>
         <relativePath>../parent/pom.xml</relativePath>
     </parent>
     <artifactId>scripting</artifactId>
@@ -52,9 +52,9 @@
     </dependencies>
     <url>http://axis.apache.org/axis2/java/core/</url>
     <scm>
-        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6/modules/scripting</connection>
-        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6/modules/scripting</developerConnection>
-        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/tags/v1.5.6/modules/scripting</url>
+        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5/modules/scripting</connection>
+        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5/modules/scripting</developerConnection>
+        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/branches/1_5/modules/scripting</url>
     </scm>
     <build>
         <sourceDirectory>src</sourceDirectory>
diff --git a/modules/soapmonitor/module/pom.xml b/modules/soapmonitor/module/pom.xml
index 3e5c8b7..d943817 100644
--- a/modules/soapmonitor/module/pom.xml
+++ b/modules/soapmonitor/module/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.axis2</groupId>
         <artifactId>axis2-parent</artifactId>
-        <version>1.5.6</version>
+        <version>1.5.7-SNAPSHOT</version>
         <relativePath>../../parent/pom.xml</relativePath>
     </parent>
     <artifactId>soapmonitor</artifactId>
@@ -45,9 +45,9 @@
     </dependencies>
     <url>http://axis.apache.org/axis2/java/core/</url>
     <scm>
-        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6/modules/soapmonitor/module</connection>
-        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6/modules/soapmonitor/module</developerConnection>
-        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/tags/v1.5.6/modules/soapmonitor/module</url>
+        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5/modules/soapmonitor/module</connection>
+        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5/modules/soapmonitor/module</developerConnection>
+        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/branches/1_5/modules/soapmonitor/module</url>
     </scm>
     <build>
         <plugins>
diff --git a/modules/soapmonitor/servlet/pom.xml b/modules/soapmonitor/servlet/pom.xml
index 9a0db8a..81ea2ab 100644
--- a/modules/soapmonitor/servlet/pom.xml
+++ b/modules/soapmonitor/servlet/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.axis2</groupId>
         <artifactId>axis2-parent</artifactId>
-        <version>1.5.6</version>
+        <version>1.5.7-SNAPSHOT</version>
         <relativePath>../../parent/pom.xml</relativePath>
     </parent>
     <artifactId>axis2-soapmonitor-servlet</artifactId>
@@ -43,9 +43,9 @@
     </dependencies>
     <url>http://axis.apache.org/axis2/java/core/</url>
     <scm>
-        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6/modules/soapmonitor/servlet</connection>
-        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6/modules/soapmonitor/servlet</developerConnection>
-        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/tags/v1.5.6/modules/soapmonitor/servlet</url>
+        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5/modules/soapmonitor/servlet</connection>
+        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5/modules/soapmonitor/servlet</developerConnection>
+        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/branches/1_5/modules/soapmonitor/servlet</url>
     </scm>
     <build>
         <plugins>
diff --git a/modules/spring/pom.xml b/modules/spring/pom.xml
index 3d5d5cf..fd62af1 100644
--- a/modules/spring/pom.xml
+++ b/modules/spring/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.axis2</groupId>
         <artifactId>axis2-parent</artifactId>
-        <version>1.5.6</version>
+        <version>1.5.7-SNAPSHOT</version>
         <relativePath>../parent/pom.xml</relativePath>
     </parent>
     <artifactId>axis2-spring</artifactId>
@@ -55,9 +55,9 @@
     </dependencies>
     <url>http://axis.apache.org/axis2/java/core/</url>
     <scm>
-        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6/modules/spring</connection>
-        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6/modules/spring</developerConnection>
-        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/tags/v1.5.6/modules/spring</url>
+        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5/modules/spring</connection>
+        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5/modules/spring</developerConnection>
+        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/branches/1_5/modules/spring</url>
     </scm>
     <build>
         <sourceDirectory>src</sourceDirectory>
diff --git a/modules/testutils/pom.xml b/modules/testutils/pom.xml
index 248d2cf..a9f8969 100644
--- a/modules/testutils/pom.xml
+++ b/modules/testutils/pom.xml
@@ -22,7 +22,7 @@
     <parent>
         <groupId>org.apache.axis2</groupId>
         <artifactId>axis2-parent</artifactId>
-        <version>1.5.6</version>
+        <version>1.5.7-SNAPSHOT</version>
         <relativePath>../parent/pom.xml</relativePath>
     </parent>
     <artifactId>axis2-testutils</artifactId>
@@ -37,9 +37,9 @@
     </dependencies>
     <url>http://axis.apache.org/axis2/java/core/</url>
     <scm>
-        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6/modules/testutils</connection>
-        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6/modules/testutils</developerConnection>
-        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/tags/v1.5.6/modules/testutils</url>
+        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5/modules/testutils</connection>
+        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5/modules/testutils</developerConnection>
+        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/branches/1_5/modules/testutils</url>
     </scm>
     <build>
         <plugins>
diff --git a/modules/tool/axis2-aar-maven-plugin/pom.xml b/modules/tool/axis2-aar-maven-plugin/pom.xml
index ab6cd64..d744451 100644
--- a/modules/tool/axis2-aar-maven-plugin/pom.xml
+++ b/modules/tool/axis2-aar-maven-plugin/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.axis2</groupId>
         <artifactId>axis2-parent</artifactId>
-        <version>1.5.6</version>
+        <version>1.5.7-SNAPSHOT</version>
         <relativePath>../../parent/pom.xml</relativePath>
     </parent>
     <artifactId>axis2-aar-maven-plugin</artifactId>
@@ -67,9 +67,9 @@
     </dependencies>
     <url>http://axis.apache.org/axis2/java/core/</url>
     <scm>
-        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6/modules/tool/axis2-aar-maven-plugin</connection>
-        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6/modules/tool/axis2-aar-maven-plugin</developerConnection>
-        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/tags/v1.5.6/modules/tool/axis2-aar-maven-plugin</url>
+        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5/modules/tool/axis2-aar-maven-plugin</connection>
+        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5/modules/tool/axis2-aar-maven-plugin</developerConnection>
+        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/branches/1_5/modules/tool/axis2-aar-maven-plugin</url>
     </scm>
     <build>
         <plugins>
diff --git a/modules/tool/axis2-ant-plugin/pom.xml b/modules/tool/axis2-ant-plugin/pom.xml
index 2cbebd1..730dc0c 100644
--- a/modules/tool/axis2-ant-plugin/pom.xml
+++ b/modules/tool/axis2-ant-plugin/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.axis2</groupId>
         <artifactId>axis2-parent</artifactId>
-        <version>1.5.6</version>
+        <version>1.5.7-SNAPSHOT</version>
         <relativePath>../../parent/pom.xml</relativePath>
     </parent>
     <artifactId>axis2-ant-plugin</artifactId>
@@ -32,9 +32,9 @@
     <description>The Axis 2 Plugin for Ant Tasks.</description>
     <url>http://axis.apache.org/axis2/java/core/</url>
     <scm>
-        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6/modules/tool/axis2-ant-plugin</connection>
-        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6/modules/tool/axis2-ant-plugin</developerConnection>
-        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/tags/v1.5.6/modules/tool/axis2-ant-plugin</url>
+        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5/modules/tool/axis2-ant-plugin</connection>
+        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5/modules/tool/axis2-ant-plugin</developerConnection>
+        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/branches/1_5/modules/tool/axis2-ant-plugin</url>
     </scm>
     <dependencies>
         <dependency>
diff --git a/modules/tool/axis2-eclipse-codegen-plugin/pom.xml b/modules/tool/axis2-eclipse-codegen-plugin/pom.xml
index 6089ab5..85b48bf 100644
--- a/modules/tool/axis2-eclipse-codegen-plugin/pom.xml
+++ b/modules/tool/axis2-eclipse-codegen-plugin/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.axis2</groupId>
         <artifactId>axis2-parent</artifactId>
-        <version>1.5.6</version>
+        <version>1.5.7-SNAPSHOT</version>
         <relativePath>../../parent/pom.xml</relativePath>
     </parent>
     <artifactId>axis2.eclipse.codegen.plugin</artifactId>
@@ -33,9 +33,9 @@
     <description>The Axis 2 Eclipse Codegen Plugin for wsdl2java and java2wsdl</description>
     <url>http://axis.apache.org/axis2/java/core/</url>
     <scm>
-        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6/modules/tool/axis2-eclipse-codegen-plugin</connection>
-        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6/modules/tool/axis2-eclipse-codegen-plugin</developerConnection>
-        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/tags/v1.5.6/modules/tool/axis2-eclipse-codegen-plugin</url>
+        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5/modules/tool/axis2-eclipse-codegen-plugin</connection>
+        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5/modules/tool/axis2-eclipse-codegen-plugin</developerConnection>
+        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/branches/1_5/modules/tool/axis2-eclipse-codegen-plugin</url>
     </scm>
     <dependencies>
         <dependency>
diff --git a/modules/tool/axis2-eclipse-service-plugin/pom.xml b/modules/tool/axis2-eclipse-service-plugin/pom.xml
index 9e6716f..c160fa5 100644
--- a/modules/tool/axis2-eclipse-service-plugin/pom.xml
+++ b/modules/tool/axis2-eclipse-service-plugin/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.axis2</groupId>
         <artifactId>axis2-parent</artifactId>
-        <version>1.5.6</version>
+        <version>1.5.7-SNAPSHOT</version>
         <relativePath>../../parent/pom.xml</relativePath>
     </parent>
     <artifactId>axis2.eclipse.service.plugin</artifactId>
@@ -33,9 +33,9 @@
     <description>The Axis 2 Eclipse Service Plugin for Service archive creation</description>
     <url>http://axis.apache.org/axis2/java/core/</url>
     <scm>
-        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6/modules/tool/axis2-eclipse-service-plugin</connection>
-        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6/modules/tool/axis2-eclipse-service-plugin</developerConnection>
-        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/tags/v1.5.6/modules/tool/axis2-eclipse-service-plugin</url>
+        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5/modules/tool/axis2-eclipse-service-plugin</connection>
+        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5/modules/tool/axis2-eclipse-service-plugin</developerConnection>
+        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/branches/1_5/modules/tool/axis2-eclipse-service-plugin</url>
     </scm>
     <dependencies>
         <dependency>
diff --git a/modules/tool/axis2-idea-plugin/pom.xml b/modules/tool/axis2-idea-plugin/pom.xml
index a598ee3..e34978b 100644
--- a/modules/tool/axis2-idea-plugin/pom.xml
+++ b/modules/tool/axis2-idea-plugin/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.axis2</groupId>
         <artifactId>axis2-parent</artifactId>
-        <version>1.5.6</version>
+        <version>1.5.7-SNAPSHOT</version>
         <relativePath>../../parent/pom.xml</relativePath>
     </parent>
     <artifactId>axis2-idea-plugin</artifactId>
@@ -34,9 +34,9 @@
     </description>
     <url>http://axis.apache.org/axis2/java/core/</url>
     <scm>
-        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6/modules/tool/axis2-idea-plugin</connection>
-        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6/modules/tool/axis2-idea-plugin</developerConnection>
-        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/tags/v1.5.6/modules/tool/axis2-idea-plugin</url>
+        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5/modules/tool/axis2-idea-plugin</connection>
+        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5/modules/tool/axis2-idea-plugin</developerConnection>
+        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/branches/1_5/modules/tool/axis2-idea-plugin</url>
     </scm>
     <dependencies>
         <dependency>
diff --git a/modules/tool/axis2-java2wsdl-maven-plugin/pom.xml b/modules/tool/axis2-java2wsdl-maven-plugin/pom.xml
index fc47fb0..c12d530 100644
--- a/modules/tool/axis2-java2wsdl-maven-plugin/pom.xml
+++ b/modules/tool/axis2-java2wsdl-maven-plugin/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.axis2</groupId>
         <artifactId>axis2-parent</artifactId>
-        <version>1.5.6</version>
+        <version>1.5.7-SNAPSHOT</version>
         <relativePath>../../parent/pom.xml</relativePath>
     </parent>
     <artifactId>axis2-java2wsdl-maven-plugin</artifactId>
@@ -35,9 +35,9 @@
     <packaging>maven-plugin</packaging>
     <url>http://axis.apache.org/axis2/java/core/</url>
     <scm>
-        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6/modules/tool/axis2-java2wsdl-maven-plugin</connection>
-        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6/modules/tool/axis2-java2wsdl-maven-plugin</developerConnection>
-        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/tags/v1.5.6/modules/tool/axis2-java2wsdl-maven-plugin</url>
+        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5/modules/tool/axis2-java2wsdl-maven-plugin</connection>
+        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5/modules/tool/axis2-java2wsdl-maven-plugin</developerConnection>
+        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/branches/1_5/modules/tool/axis2-java2wsdl-maven-plugin</url>
     </scm>
     <build>
         <sourceDirectory>src/main/java</sourceDirectory>
diff --git a/modules/tool/axis2-mar-maven-plugin/pom.xml b/modules/tool/axis2-mar-maven-plugin/pom.xml
index adc6eb4..cd4aac8 100644
--- a/modules/tool/axis2-mar-maven-plugin/pom.xml
+++ b/modules/tool/axis2-mar-maven-plugin/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.axis2</groupId>
         <artifactId>axis2-parent</artifactId>
-        <version>1.5.6</version>
+        <version>1.5.7-SNAPSHOT</version>
         <relativePath>../../parent/pom.xml</relativePath>
     </parent>
     <artifactId>axis2-mar-maven-plugin</artifactId>
@@ -68,9 +68,9 @@
     </dependencies>
     <url>http://axis.apache.org/axis2/java/core/</url>
     <scm>
-        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6/modules/tool/axis2-mar-maven-plugin</connection>
-        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6/modules/tool/axis2-mar-maven-plugin</developerConnection>
-        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/tags/v1.5.6/modules/tool/axis2-mar-maven-plugin</url>
+        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5/modules/tool/axis2-mar-maven-plugin</connection>
+        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5/modules/tool/axis2-mar-maven-plugin</developerConnection>
+        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/branches/1_5/modules/tool/axis2-mar-maven-plugin</url>
     </scm>
     <build>
         <plugins>
diff --git a/modules/tool/axis2-repo-maven-plugin/pom.xml b/modules/tool/axis2-repo-maven-plugin/pom.xml
index 12d9bdb..023ef27 100644
--- a/modules/tool/axis2-repo-maven-plugin/pom.xml
+++ b/modules/tool/axis2-repo-maven-plugin/pom.xml
@@ -22,7 +22,7 @@
     <parent>
         <groupId>org.apache.axis2</groupId>
         <artifactId>axis2-parent</artifactId>
-        <version>1.5.6</version>
+        <version>1.5.7-SNAPSHOT</version>
         <relativePath>../../parent/pom.xml</relativePath>
     </parent>
     <artifactId>axis2-repo-maven-plugin</artifactId>
@@ -48,9 +48,9 @@
     </dependencies>
     <url>http://axis.apache.org/axis2/java/core/</url>
     <scm>
-        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6/modules/tool/axis2-repo-maven-plugin</connection>
-        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6/modules/tool/axis2-repo-maven-plugin</developerConnection>
-        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/tags/v1.5.6/modules/tool/axis2-repo-maven-plugin</url>
+        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5/modules/tool/axis2-repo-maven-plugin</connection>
+        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5/modules/tool/axis2-repo-maven-plugin</developerConnection>
+        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/branches/1_5/modules/tool/axis2-repo-maven-plugin</url>
     </scm>
     <build>
         <plugins>
diff --git a/modules/tool/axis2-wsdl2code-maven-plugin/pom.xml b/modules/tool/axis2-wsdl2code-maven-plugin/pom.xml
index 468bdfc..ca0ba93 100644
--- a/modules/tool/axis2-wsdl2code-maven-plugin/pom.xml
+++ b/modules/tool/axis2-wsdl2code-maven-plugin/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.axis2</groupId>
         <artifactId>axis2-parent</artifactId>
-        <version>1.5.6</version>
+        <version>1.5.7-SNAPSHOT</version>
         <relativePath>../../parent/pom.xml</relativePath>
     </parent>
     <artifactId>axis2-wsdl2code-maven-plugin</artifactId>
@@ -33,9 +33,9 @@
     <description>The Axis 2 Plugin for Maven allows client side and server side sources from a WSDL.</description>
     <url>http://axis.apache.org/axis2/java/core/</url>
     <scm>
-        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6/modules/tool/axis2-wsdl2code-maven-plugin</connection>
-        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6/modules/tool/axis2-wsdl2code-maven-plugin</developerConnection>
-        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/tags/v1.5.6/modules/tool/axis2-wsdl2code-maven-plugin</url>
+        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5/modules/tool/axis2-wsdl2code-maven-plugin</connection>
+        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5/modules/tool/axis2-wsdl2code-maven-plugin</developerConnection>
+        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/branches/1_5/modules/tool/axis2-wsdl2code-maven-plugin</url>
     </scm>
     <dependencies>
         <dependency>
diff --git a/modules/transport/http/pom.xml b/modules/transport/http/pom.xml
index 7a98e76..53ebecc 100644
--- a/modules/transport/http/pom.xml
+++ b/modules/transport/http/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.axis2</groupId>
         <artifactId>axis2-parent</artifactId>
-        <version>1.5.6</version>
+        <version>1.5.7-SNAPSHOT</version>
         <relativePath>../../parent/pom.xml</relativePath>
     </parent>
     <artifactId>axis2-transport-http</artifactId>
@@ -33,9 +33,9 @@
     <packaging>bundle</packaging>
     <url>http://axis.apache.org/axis2/java/core/</url>
     <scm>
-        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6/modules/transport/http</connection>
-        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6/modules/transport/http</developerConnection>
-        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/tags/v1.5.6/modules/transport/http</url>
+        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5/modules/transport/http</connection>
+        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5/modules/transport/http</developerConnection>
+        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/branches/1_5/modules/transport/http</url>
     </scm>
     <build>
         <sourceDirectory>src</sourceDirectory>
diff --git a/modules/transport/local/pom.xml b/modules/transport/local/pom.xml
index f2d13db..536091c 100644
--- a/modules/transport/local/pom.xml
+++ b/modules/transport/local/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.axis2</groupId>
         <artifactId>axis2-parent</artifactId>
-        <version>1.5.6</version>
+        <version>1.5.7-SNAPSHOT</version>
         <relativePath>../../parent/pom.xml</relativePath>
     </parent>
     <artifactId>axis2-transport-local</artifactId>
@@ -33,9 +33,9 @@
     <packaging>bundle</packaging>
     <url>http://axis.apache.org/axis2/java/core/</url>
     <scm>
-        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6/modules/transport/local</connection>
-        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6/modules/transport/local</developerConnection>
-        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/tags/v1.5.6/modules/transport/local</url>
+        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5/modules/transport/local</connection>
+        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5/modules/transport/local</developerConnection>
+        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/branches/1_5/modules/transport/local</url>
     </scm>
     <build>
         <sourceDirectory>src</sourceDirectory>
diff --git a/modules/webapp/pom.xml b/modules/webapp/pom.xml
index 4b5379e..649a69e 100644
--- a/modules/webapp/pom.xml
+++ b/modules/webapp/pom.xml
@@ -22,7 +22,7 @@
     <parent>
         <groupId>org.apache.axis2</groupId>
         <artifactId>axis2-parent</artifactId>
-        <version>1.5.6</version>
+        <version>1.5.7-SNAPSHOT</version>
         <relativePath>../parent/pom.xml</relativePath>
     </parent>
     <artifactId>axis2-webapp</artifactId>
@@ -30,9 +30,9 @@
     <name>Apache Axis2 - Web Application module</name>
     <url>http://axis.apache.org/axis2/java/core/</url>
     <scm>
-        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6/modules/webapp</connection>
-        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6/modules/webapp</developerConnection>
-        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/tags/v1.5.6/modules/webapp</url>
+        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5/modules/webapp</connection>
+        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5/modules/webapp</developerConnection>
+        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/branches/1_5/modules/webapp</url>
     </scm>
     <dependencies>
         <dependency>
diff --git a/modules/xmlbeans/pom.xml b/modules/xmlbeans/pom.xml
index 5d7ecaa..724a4e0 100644
--- a/modules/xmlbeans/pom.xml
+++ b/modules/xmlbeans/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.axis2</groupId>
         <artifactId>axis2-parent</artifactId>
-        <version>1.5.6</version>
+        <version>1.5.7-SNAPSHOT</version>
         <relativePath>../parent/pom.xml</relativePath>
     </parent>
     <artifactId>axis2-xmlbeans</artifactId>
@@ -51,9 +51,9 @@
     </dependencies>
     <url>http://axis.apache.org/axis2/java/core/</url>
     <scm>
-        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6/modules/xmlbeans</connection>
-        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6/modules/xmlbeans</developerConnection>
-        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/tags/v1.5.6/modules/xmlbeans</url>
+        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5/modules/xmlbeans</connection>
+        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5/modules/xmlbeans</developerConnection>
+        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/branches/1_5/modules/xmlbeans</url>
     </scm>
     <build>
         <resources>
diff --git a/pom.xml b/pom.xml
index 37cee92..68ec16f 100644
--- a/pom.xml
+++ b/pom.xml
@@ -28,7 +28,7 @@
     <modelVersion>4.0.0</modelVersion>
     <groupId>org.apache.axis2</groupId>
     <artifactId>axis2</artifactId>
-    <version>1.5.6</version>
+    <version>1.5.7-SNAPSHOT</version>
     <packaging>pom</packaging>
     <name>Apache Axis2 - Root</name>
     <inceptionYear>2004</inceptionYear>
@@ -526,9 +526,9 @@
 
     </contributors>
     <scm>
-        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6</connection>
-        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/tags/v1.5.6</developerConnection>
-        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/tags/v1.5.6</url>
+        <connection>scm:svn:http://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5</connection>
+        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/axis/axis2/java/core/branches/1_5</developerConnection>
+        <url>http://svn.apache.org/viewvc/axis/axis2/java/core/branches/1_5</url>
     </scm>
     <properties>
         <!-- This variable is used in some Xdocs and is substituted using Velocity. Note that


[axis-axis2-java-core] 26/38: Switched the Axis2 1.5 branch to Axiom 1.2.13.

Posted by bi...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

billblough pushed a commit to branch 1_5
in repository https://gitbox.apache.org/repos/asf/axis-axis2-java-core.git

commit 27919d3ef76b1668f933f4277853e98fd25d56c6
Author: Andreas Veithen <ve...@apache.org>
AuthorDate: Mon Apr 9 14:19:03 2012 +0000

    Switched the Axis2 1.5 branch to Axiom 1.2.13.
---
 modules/parent/pom.xml | 3 +--
 1 file changed, 1 insertion(+), 2 deletions(-)

diff --git a/modules/parent/pom.xml b/modules/parent/pom.xml
index 30b02b9..86287c7 100644
--- a/modules/parent/pom.xml
+++ b/modules/parent/pom.xml
@@ -68,8 +68,7 @@
     <properties>
         <ant.version>1.7.0</ant.version>
         <antlr.version>2.7.7</antlr.version>
-        <!-- Need to ship Axis2 1.5.7 with Axiom 1.2.13 because of RAMPART-336 -->
-        <axiom.version>1.2.13-SNAPSHOT</axiom.version>
+        <axiom.version>1.2.13</axiom.version>
         <bsf.version>2.4.0</bsf.version>
         <commons.codec.version>1.3</commons.codec.version>
         <commons.fileupload.version>1.2</commons.fileupload.version>


[axis-axis2-java-core] 21/38: Merged r1297765 to the 1.5 branch.

Posted by bi...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

billblough pushed a commit to branch 1_5
in repository https://gitbox.apache.org/repos/asf/axis-axis2-java-core.git

commit fde252cad0415a0fe21ffd025cf707ac76691681
Author: Andreas Veithen <ve...@apache.org>
AuthorDate: Wed Mar 7 20:59:11 2012 +0000

    Merged r1297765 to the 1.5 branch.
---
 modules/saaj/src/org/apache/axis2/saaj/SOAPEnvelopeImpl.java | 6 ------
 1 file changed, 6 deletions(-)

diff --git a/modules/saaj/src/org/apache/axis2/saaj/SOAPEnvelopeImpl.java b/modules/saaj/src/org/apache/axis2/saaj/SOAPEnvelopeImpl.java
index 328fae0..9d70ef2 100644
--- a/modules/saaj/src/org/apache/axis2/saaj/SOAPEnvelopeImpl.java
+++ b/modules/saaj/src/org/apache/axis2/saaj/SOAPEnvelopeImpl.java
@@ -21,7 +21,6 @@ package org.apache.axis2.saaj;
 
 import org.apache.axiom.om.OMNode;
 import org.apache.axiom.om.impl.dom.ChildNode;
-import org.apache.axiom.om.impl.dom.DocumentImpl;
 import org.apache.axiom.om.impl.dom.NodeImpl;
 import org.apache.axiom.om.impl.dom.TextImpl;
 import org.apache.axiom.soap.SOAPFactory;
@@ -30,7 +29,6 @@ import org.apache.axiom.soap.impl.dom.soap11.SOAP11Factory;
 import org.apache.axiom.soap.impl.dom.soap11.SOAP11HeaderImpl;
 import org.apache.axiom.soap.impl.dom.soap12.SOAP12Factory;
 import org.apache.axiom.soap.impl.dom.soap12.SOAP12HeaderImpl;
-import org.w3c.dom.Document;
 import org.w3c.dom.Node;
 
 import javax.xml.soap.Name;
@@ -52,10 +50,6 @@ public class SOAPEnvelopeImpl extends SOAPElementImpl implements javax.xml.soap.
         omSOAPEnvelope = envelope;
     }
 
-    public void setOwnerDocument(Document document) {
-        super.setOwnerDocument((DocumentImpl)document);
-    }
-
     public org.apache.axiom.soap.SOAPEnvelope getOMEnvelope() {
         return omSOAPEnvelope;
     }


[axis-axis2-java-core] 38/38: Merged 1359504 to 1.5 branch.

Posted by bi...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

billblough pushed a commit to branch 1_5
in repository https://gitbox.apache.org/repos/asf/axis-axis2-java-core.git

commit 93c490c3c647996a2ed6640feef3f6fd61eb1599
Author: Sagara Gunathunga <sa...@apache.org>
AuthorDate: Tue Jul 10 07:29:46 2012 +0000

     Merged 1359504 to 1.5 branch.
---
 .../src/main/java/org/apache/axis2/maven2/wsdl2code/WSDL2CodeMojo.java | 3 +--
 1 file changed, 1 insertion(+), 2 deletions(-)

diff --git a/modules/tool/axis2-wsdl2code-maven-plugin/src/main/java/org/apache/axis2/maven2/wsdl2code/WSDL2CodeMojo.java b/modules/tool/axis2-wsdl2code-maven-plugin/src/main/java/org/apache/axis2/maven2/wsdl2code/WSDL2CodeMojo.java
index d2cb02d..414361e 100644
--- a/modules/tool/axis2-wsdl2code-maven-plugin/src/main/java/org/apache/axis2/maven2/wsdl2code/WSDL2CodeMojo.java
+++ b/modules/tool/axis2-wsdl2code-maven-plugin/src/main/java/org/apache/axis2/maven2/wsdl2code/WSDL2CodeMojo.java
@@ -72,8 +72,7 @@ public class WSDL2CodeMojo extends AbstractMojo {
      * Package name of the generated sources; will be used to create a package structure below the
      * output directory.
      *
-     * @parameter expression="${axis2.wsdl2code.package}"
-     * @required
+     * @parameter expression="${axis2.wsdl2code.package}"     * 
      */
     private String packageName;
 


[axis-axis2-java-core] 25/38: Merged r1300358 to the 1.5 branch.

Posted by bi...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

billblough pushed a commit to branch 1_5
in repository https://gitbox.apache.org/repos/asf/axis-axis2-java-core.git

commit a41bfca7ba683c6944f9b92fe75a97d450ca534e
Author: Andreas Veithen <ve...@apache.org>
AuthorDate: Tue Mar 13 21:33:29 2012 +0000

    Merged r1300358 to the 1.5 branch.
---
 .../src/org/apache/axis2/saaj/MessageFactoryImpl.java     | 15 +++++++--------
 1 file changed, 7 insertions(+), 8 deletions(-)

diff --git a/modules/saaj/src/org/apache/axis2/saaj/MessageFactoryImpl.java b/modules/saaj/src/org/apache/axis2/saaj/MessageFactoryImpl.java
index 19365a8..6722ca0 100644
--- a/modules/saaj/src/org/apache/axis2/saaj/MessageFactoryImpl.java
+++ b/modules/saaj/src/org/apache/axis2/saaj/MessageFactoryImpl.java
@@ -96,21 +96,20 @@ public class MessageFactoryImpl extends MessageFactory {
      *                       protocol of this MessageFactory instance is DYNAMIC_SOAP_PROTOCOL
      */
     public SOAPMessage createMessage() throws SOAPException {
-        SOAPEnvelopeImpl soapEnvelope;
+        org.apache.axiom.soap.impl.dom.SOAPEnvelopeImpl soapEnvelope;
         if (soapVersion.equals(SOAPConstants.SOAP_1_2_PROTOCOL)) {
-            soapEnvelope =
-                    new SOAPEnvelopeImpl((org.apache.axiom.soap.impl.dom.SOAPEnvelopeImpl)
-                            new SOAP12Factory().getDefaultEnvelope());
+            soapEnvelope = (org.apache.axiom.soap.impl.dom.SOAPEnvelopeImpl)
+                            new SOAP12Factory().getDefaultEnvelope();
         } else if (soapVersion.equals(SOAPConstants.DYNAMIC_SOAP_PROTOCOL)) {
             throw new UnsupportedOperationException("createMessage() is not supported for " +
                     "DYNAMIC_SOAP_PROTOCOL");
         } else {
             //SOAP 1.1
-            soapEnvelope =
-                    new SOAPEnvelopeImpl((org.apache.axiom.soap.impl.dom.SOAPEnvelopeImpl)
-                            new SOAP11Factory().getDefaultEnvelope());
+            soapEnvelope = (org.apache.axiom.soap.impl.dom.SOAPEnvelopeImpl)
+                            new SOAP11Factory().getDefaultEnvelope();
         }
-        SOAPMessageImpl soapMessage = new SOAPMessageImpl(soapEnvelope);
+        soapEnvelope.getOwnerDocument().appendChild(soapEnvelope);
+        SOAPMessageImpl soapMessage = new SOAPMessageImpl(new SOAPEnvelopeImpl(soapEnvelope));
         soapMessage.setSaveRequired();
         return soapMessage;
     }


[axis-axis2-java-core] 10/38: AXIS2-5173: Merged r835745 to the 1.5 branch.

Posted by bi...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

billblough pushed a commit to branch 1_5
in repository https://gitbox.apache.org/repos/asf/axis-axis2-java-core.git

commit 7be8bc96ff719d01beda963ea3f777f5d48e7d9e
Author: Andreas Veithen <ve...@apache.org>
AuthorDate: Sat Oct 29 16:04:12 2011 +0000

    AXIS2-5173: Merged r835745 to the 1.5 branch.
---
 .../org/apache/axis2/jaxbri/CodeGenerationUtility.java    | 15 +++++++++++++++
 1 file changed, 15 insertions(+)

diff --git a/modules/jaxbri/src/org/apache/axis2/jaxbri/CodeGenerationUtility.java b/modules/jaxbri/src/org/apache/axis2/jaxbri/CodeGenerationUtility.java
index 132c37a..bd19793 100644
--- a/modules/jaxbri/src/org/apache/axis2/jaxbri/CodeGenerationUtility.java
+++ b/modules/jaxbri/src/org/apache/axis2/jaxbri/CodeGenerationUtility.java
@@ -201,6 +201,21 @@ public class CodeGenerationUtility {
                 });
 
                 sc.parseSchema((InputSource) schemaToInputSourceMap.get(key));
+                sc.getOptions().addGrammar((InputSource) schemaToInputSourceMap.get(key));
+
+                for (Object property : properties.keySet()){
+                    String propertyName = (String) property;
+                    if (propertyName.startsWith("X")) {
+                        String[] args = null;
+                        String propertyValue = (String) properties.get(property);
+                        if (propertyValue != null) {
+                            args = new String[]{"-" + propertyName, propertyValue};
+                        } else {
+                            args = new String[]{"-" + propertyName};
+                        }
+                        sc.getOptions().parseArguments(args);
+                    }
+                }
 
                 // Bind the XML
                 S2JJAXBModel jaxbModel = sc.bind();


[axis-axis2-java-core] 14/38: Merged r1201467 to the 1.5 branch to make sure that the build succeeds with Axiom 1.2.13-SNAPSHOT.

Posted by bi...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

billblough pushed a commit to branch 1_5
in repository https://gitbox.apache.org/repos/asf/axis-axis2-java-core.git

commit 0ce4c8f541c8b93affad6c8a82a497df97be22ce
Author: Andreas Veithen <ve...@apache.org>
AuthorDate: Tue Nov 15 10:04:05 2011 +0000

    Merged r1201467 to the 1.5 branch to make sure that the build succeeds with Axiom 1.2.13-SNAPSHOT.
---
 .../src/org/apache/axis2/saaj/SOAPElementImpl.java | 32 ++++++++++++----------
 .../org/apache/axis2/saaj/SOAPElementTest.java     | 26 ++++++++++++++++++
 2 files changed, 43 insertions(+), 15 deletions(-)

diff --git a/modules/saaj/src/org/apache/axis2/saaj/SOAPElementImpl.java b/modules/saaj/src/org/apache/axis2/saaj/SOAPElementImpl.java
index 991b8c8..5e1e293 100644
--- a/modules/saaj/src/org/apache/axis2/saaj/SOAPElementImpl.java
+++ b/modules/saaj/src/org/apache/axis2/saaj/SOAPElementImpl.java
@@ -173,10 +173,23 @@ public class SOAPElementImpl extends NodeImplEx implements SOAPElement {
     /* (non-Javadoc)
     * @see javax.xml.soap.SOAPElement#addChildElement(java.lang.String, java.lang.String, java.lang.String)
     */
-    public SOAPElement addChildElement(String localName, String prefix, String uri)
+    public SOAPElement addChildElement(String localName, String prefix, String namespaceURI)
             throws SOAPException {
-        OMNamespace omNamespace = prefix == null || prefix.length() == 0 ? element.declareDefaultNamespace(uri) : element.declareNamespace(uri, prefix);
-        return addChildElement(localName, omNamespace.getPrefix());
+        if (prefix == null) {
+            prefix = "";
+        }
+        SOAPElementImpl childEle =
+                new SOAPElementImpl((ElementImpl)getOwnerDocument().
+                        createElementNS(namespaceURI, prefix.length() == 0 ? localName : prefix + ":" + localName));
+    
+        childEle.element.setUserData(SAAJ_NODE, childEle, null);
+        childEle.element.setNamespace(prefix.length() == 0
+                ? childEle.element.declareDefaultNamespace(namespaceURI)
+                : childEle.element.declareNamespace(namespaceURI, prefix));
+        element.appendChild(childEle.element);
+        ((NodeImpl)childEle.element.getParentNode()).setUserData(SAAJ_NODE, this, null);
+        childEle.setParentElement(this);
+        return childEle;
     }
 
     /* (non-Javadoc)
@@ -189,18 +202,7 @@ public class SOAPElementImpl extends NodeImplEx implements SOAPElement {
             throw new SOAPException("Namespace not declared for the give prefix: " + prefix);
         }
 
-        SOAPElementImpl childEle =
-                new SOAPElementImpl((ElementImpl)getOwnerDocument().
-                        createElementNS(namespaceURI, prefix + ":" + localName));
-
-        childEle.element.setUserData(SAAJ_NODE, childEle, null);
-        childEle.element.setNamespace(prefix == null || prefix.length() == 0
-                ? childEle.element.declareDefaultNamespace(namespaceURI)
-                : childEle.element.declareNamespace(namespaceURI, prefix));
-        element.appendChild(childEle.element);
-        ((NodeImpl)childEle.element.getParentNode()).setUserData(SAAJ_NODE, this, null);
-        childEle.setParentElement(this);
-        return childEle;
+        return addChildElement(localName, prefix, namespaceURI);
     }
 
     /* (non-Javadoc)
diff --git a/modules/saaj/test/org/apache/axis2/saaj/SOAPElementTest.java b/modules/saaj/test/org/apache/axis2/saaj/SOAPElementTest.java
index c386527..370535c 100644
--- a/modules/saaj/test/org/apache/axis2/saaj/SOAPElementTest.java
+++ b/modules/saaj/test/org/apache/axis2/saaj/SOAPElementTest.java
@@ -38,6 +38,7 @@ import javax.xml.soap.SOAPConstants;
 import javax.xml.soap.SOAPElement;
 import javax.xml.soap.SOAPEnvelope;
 import javax.xml.soap.SOAPException;
+import javax.xml.soap.SOAPFactory;
 import javax.xml.soap.SOAPHeader;
 import javax.xml.soap.SOAPMessage;
 import javax.xml.soap.SOAPPart;
@@ -196,6 +197,31 @@ public class SOAPElementTest extends Assert {
     }
 
     @Validated @Test
+    public void testAddChildElementWithUndeclaredNamespace() throws Exception {
+        SOAPElement element = SOAPFactory.newInstance().createElement("test");
+        SOAPElement child = element.addChildElement("test", "p", "urn:ns");
+        assertEquals(0, element.getAttributes().getLength());
+        assertEquals("urn:ns", child.getNamespaceURI());
+        assertEquals("p", child.getPrefix());
+        assertEquals("test", child.getLocalName());
+        Attr nsDecl = child.getAttributeNodeNS(XMLConstants.XMLNS_ATTRIBUTE_NS_URI, "p");
+        assertNotNull(nsDecl);
+        assertEquals("urn:ns", nsDecl.getValue());
+    }
+    
+    @Validated @Test
+    public void testAddChildElementWithDeclaredNamespace() throws Exception {
+        SOAPElement element = SOAPFactory.newInstance().createElement("test");
+        element.setAttributeNS(XMLConstants.XMLNS_ATTRIBUTE_NS_URI, "xmlns:p", "urn:ns");
+        SOAPElement child = element.addChildElement("test", "p", "urn:ns");
+        assertEquals("urn:ns", child.getNamespaceURI());
+        assertEquals("p", child.getPrefix());
+        assertEquals("test", child.getLocalName());
+        // TODO: don't know how to fix this :-(
+//        assertEquals(0, child.getAttributes().getLength());
+    }
+    
+    @Validated @Test
     public void testAddChildElement() throws Exception {
         String s = "MyName1";
         String p = "MyPrefix1";


[axis-axis2-java-core] 17/38: Merged r1231470 to the 1.5 branch.

Posted by bi...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

billblough pushed a commit to branch 1_5
in repository https://gitbox.apache.org/repos/asf/axis-axis2-java-core.git

commit fe0e2aed0a17d7bdca5393bc19e9d5245a5983ad
Author: Sagara Gunathunga <sa...@apache.org>
AuthorDate: Sat Jan 14 09:19:46 2012 +0000

    Merged r1231470 to the 1.5 branch.
---
 modules/samples/pojo/README.txt | 4 ++++
 modules/samples/pojo/build.xml  | 2 +-
 2 files changed, 5 insertions(+), 1 deletion(-)

diff --git a/modules/samples/pojo/README.txt b/modules/samples/pojo/README.txt
index eb410be..c06177c 100644
--- a/modules/samples/pojo/README.txt
+++ b/modules/samples/pojo/README.txt
@@ -16,6 +16,10 @@ To build the sample service you must have ant-1.6.x installed in your system.
 To set AXIS2_HOME in Unix/Linux type:
 $export AXIS2_HOME=<path to axis2 distribution>
 
+xerces.jar (Containing the intersection of the contents of xercesImpl.jar and xml-apis.jar)
+You need to have this jar in your build and runtime class path. The easiest way to do this
+is to copy it to Axis2_HOME/lib directory.
+
 Building the Service
 ====================
 
diff --git a/modules/samples/pojo/build.xml b/modules/samples/pojo/build.xml
index f5d6edc..7c640ca 100644
--- a/modules/samples/pojo/build.xml
+++ b/modules/samples/pojo/build.xml
@@ -115,7 +115,7 @@
 	</target>
 
 	<target name="print-usage" unless="parameters.set">
-		<echo message="ant adb.client -Dwsdl='http://&lt;yourhost>:&lt;yourport>/axis2/services/AdressBookService?wsdl'" />
+		<echo message="ant adb.client -Dwsdl='http://&lt;yourhost>:&lt;yourport>/axis2/services/AddressBookService?wsdl'" />
 	</target>
 
 	<target name="adb.client" depends="check-parameters" if="parameters.set">


[axis-axis2-java-core] 03/38: Merged r1174618 to the 1.5 branch.

Posted by bi...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

billblough pushed a commit to branch 1_5
in repository https://gitbox.apache.org/repos/asf/axis-axis2-java-core.git

commit 0c5cb2a1d2c07c2c18d69db880e7521eb5e51601
Author: Sagara Gunathunga <sa...@apache.org>
AuthorDate: Fri Sep 23 09:49:08 2011 +0000

    Merged r1174618 to the 1.5 branch.
---
 .../transport/http/src/org/apache/axis2/transport/http/HTTPWorker.java  | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)

diff --git a/modules/transport/http/src/org/apache/axis2/transport/http/HTTPWorker.java b/modules/transport/http/src/org/apache/axis2/transport/http/HTTPWorker.java
index b2f5b3b..4d30dea 100644
--- a/modules/transport/http/src/org/apache/axis2/transport/http/HTTPWorker.java
+++ b/modules/transport/http/src/org/apache/axis2/transport/http/HTTPWorker.java
@@ -80,7 +80,7 @@ public class HTTPWorker implements Worker {
                 response.addHeader(new BasicHeader("Location", contextPath));
                 return;
             }
-            if (uri.endsWith("axis2/services/")) {
+            if (uri.endsWith(contextPath)) {
                 String s = HTTPTransportReceiver.getServicesHTML(configurationContext);
                 response.setStatus(HttpStatus.SC_OK);
                 response.setContentType("text/html");


[axis-axis2-java-core] 02/38: Merged r1037135 and r1037218 to the 1.5 branch to fix the ConcurrentModificationException that sometimes causes the Hudson build to fail.

Posted by bi...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

billblough pushed a commit to branch 1_5
in repository https://gitbox.apache.org/repos/asf/axis-axis2-java-core.git

commit 3309b80ebefdae766ee9bfc8edaa999921d58be7
Author: Andreas Veithen <ve...@apache.org>
AuthorDate: Mon Sep 5 09:50:02 2011 +0000

    Merged r1037135 and r1037218 to the 1.5 branch to fix the ConcurrentModificationException that sometimes causes the Hudson build to fail.
---
 .../axis2/jaxws/client/ReleaseServiceTests.java    |  8 -------
 .../description/impl/DescriptionFactoryImpl.java   | 28 ++++++++++++----------
 2 files changed, 16 insertions(+), 20 deletions(-)

diff --git a/modules/jaxws/test/org/apache/axis2/jaxws/client/ReleaseServiceTests.java b/modules/jaxws/test/org/apache/axis2/jaxws/client/ReleaseServiceTests.java
index 803393a..36e143c 100644
--- a/modules/jaxws/test/org/apache/axis2/jaxws/client/ReleaseServiceTests.java
+++ b/modules/jaxws/test/org/apache/axis2/jaxws/client/ReleaseServiceTests.java
@@ -84,8 +84,6 @@ public class ReleaseServiceTests extends TestCase {
             epDesc= svcDesc.getEndpointDescription(portQN, delegate);
             assertNull(epDesc);                
 
-        } catch (Throwable t) {
-            fail("Caught throwable " + t);
         } finally {
             ClientMetadataTest.restoreOriginalFactory();
         }
@@ -107,8 +105,6 @@ public class ReleaseServiceTests extends TestCase {
                 svc1.addPort(portQN, bindingID1, epr1);
             }
             org.apache.axis2.jaxws.spi.ServiceDelegate.releaseService(svc1);
-        } catch (Throwable t) {
-            fail("Caught throwable " + t);
         } finally {
             ClientMetadataTest.restoreOriginalFactory();
         }
@@ -135,8 +131,6 @@ public class ReleaseServiceTests extends TestCase {
                 }
                 org.apache.axis2.jaxws.spi.ServiceDelegate.releaseService(svc1);
             }
-        } catch (Throwable t) {
-            fail("Caught throwable " + t);
         } finally {
             ClientMetadataTest.restoreOriginalFactory();
         }
@@ -541,8 +535,6 @@ public class ReleaseServiceTests extends TestCase {
                 ClientMetadataPortSEI port = genSvc.getPort(ClientMetadataPortSEI.class);
                 org.apache.axis2.jaxws.spi.ServiceDelegate.releaseService(genSvc);
             }
-        } catch (Throwable t) {
-            fail("Caught throwable " + t);
         } finally {
             ClientMetadataTest.restoreOriginalFactory();
         }
diff --git a/modules/metadata/src/org/apache/axis2/jaxws/description/impl/DescriptionFactoryImpl.java b/modules/metadata/src/org/apache/axis2/jaxws/description/impl/DescriptionFactoryImpl.java
index 51e352f..7003807 100644
--- a/modules/metadata/src/org/apache/axis2/jaxws/description/impl/DescriptionFactoryImpl.java
+++ b/modules/metadata/src/org/apache/axis2/jaxws/description/impl/DescriptionFactoryImpl.java
@@ -503,18 +503,22 @@ public class DescriptionFactoryImpl {
                     log.debug("ServiceDescription not in use; will be removed from cache");
                 }
                 svcDescRemoved = true;
-                Set<Map.Entry<DescriptionKey, ServiceDescription>> cacheEntrySet = 
-                    cache.entrySet();
-                Iterator<Map.Entry<DescriptionKey, ServiceDescription>> cacheEntryIterator =
-                    cacheEntrySet.iterator();
-                while (cacheEntryIterator.hasNext()) {
-                    Map.Entry<DescriptionKey, ServiceDescription> entry = 
-                        cacheEntryIterator.next();
-                    ServiceDescription entrySvcDescValue = entry.getValue();
-                    if (svcDesc == entrySvcDescValue) {
-                        cacheEntryIterator.remove();
-                        if (log.isDebugEnabled()) {
-                            log.debug("Removed service description from cache");
+                // Even if we use a Hashtable, we need to synchronize here to avoid
+                // ConcurrentModificationException when iterating over the entries.
+                synchronized (cache) {
+                    Set<Map.Entry<DescriptionKey, ServiceDescription>> cacheEntrySet = 
+                        cache.entrySet();
+                    Iterator<Map.Entry<DescriptionKey, ServiceDescription>> cacheEntryIterator =
+                        cacheEntrySet.iterator();
+                    while (cacheEntryIterator.hasNext()) {
+                        Map.Entry<DescriptionKey, ServiceDescription> entry = 
+                            cacheEntryIterator.next();
+                        ServiceDescription entrySvcDescValue = entry.getValue();
+                        if (svcDesc == entrySvcDescValue) {
+                            cacheEntryIterator.remove();
+                            if (log.isDebugEnabled()) {
+                                log.debug("Removed service description from cache");
+                            }
                         }
                     }
                 }


[axis-axis2-java-core] 37/38: Merged r1359499 to 1.5 branch.

Posted by bi...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

billblough pushed a commit to branch 1_5
in repository https://gitbox.apache.org/repos/asf/axis-axis2-java-core.git

commit 16c5219a8cc1df3741d3e3879f1a55f7058b952f
Author: Sagara Gunathunga <sa...@apache.org>
AuthorDate: Tue Jul 10 07:16:42 2012 +0000

     Merged r1359499 to 1.5 branch.
---
 modules/tool/axis2-wsdl2code-maven-plugin/pom.xml | 9 ++++++++-
 1 file changed, 8 insertions(+), 1 deletion(-)

diff --git a/modules/tool/axis2-wsdl2code-maven-plugin/pom.xml b/modules/tool/axis2-wsdl2code-maven-plugin/pom.xml
index ca0ba93..e4a903f 100644
--- a/modules/tool/axis2-wsdl2code-maven-plugin/pom.xml
+++ b/modules/tool/axis2-wsdl2code-maven-plugin/pom.xml
@@ -80,7 +80,14 @@
             <artifactId>axis2-xmlbeans</artifactId>
             <version>${project.version}</version>
         </dependency>
-
+        <dependency>
+            <groupId>jalopy</groupId>
+            <artifactId>jalopy</artifactId>
+        </dependency>
+        <dependency>
+        	<groupId>log4j</groupId>
+            <artifactId>log4j</artifactId>
+        </dependency>
         <dependency>
             <groupId>org.apache.maven.shared</groupId>
             <artifactId>maven-plugin-testing-harness</artifactId>


[axis-axis2-java-core] 13/38: Merged r1201957 to the 1.5 branch.

Posted by bi...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

billblough pushed a commit to branch 1_5
in repository https://gitbox.apache.org/repos/asf/axis-axis2-java-core.git

commit 6c7a3dc78d107c895ae45aac4dae8b4e927d09b4
Author: Sagara Gunathunga <sa...@apache.org>
AuthorDate: Mon Nov 14 23:06:14 2011 +0000

    Merged r1201957 to the 1.5 branch.
---
 .../http/src/org/apache/axis2/transport/http/SimpleHTTPServer.java | 7 +++----
 1 file changed, 3 insertions(+), 4 deletions(-)

diff --git a/modules/transport/http/src/org/apache/axis2/transport/http/SimpleHTTPServer.java b/modules/transport/http/src/org/apache/axis2/transport/http/SimpleHTTPServer.java
index 95af246..ecd156b 100644
--- a/modules/transport/http/src/org/apache/axis2/transport/http/SimpleHTTPServer.java
+++ b/modules/transport/http/src/org/apache/axis2/transport/http/SimpleHTTPServer.java
@@ -38,7 +38,6 @@ import org.apache.axis2.util.OptionsParser;
 import org.apache.commons.logging.Log;
 import org.apache.commons.logging.LogFactory;
 
-import javax.xml.namespace.QName;
 import java.io.File;
 import java.io.IOException;
 import java.util.Iterator;
@@ -166,11 +165,11 @@ public class SimpleHTTPServer implements TransportListener {
 
             // should all transports be started? specified as "-t all"
             if (startAllTransports) {
-                Iterator iter = configctx.getAxisConfiguration().
+                Iterator<String> iter = configctx.getAxisConfiguration().
                         getTransportsIn().keySet().iterator();
                 while (iter.hasNext()) {
-                    QName trp = (QName) iter.next();
-                    if (!new QName(Constants.TRANSPORT_HTTP).equals(trp)) {
+                    String trp = iter.next();
+                    if (!Constants.TRANSPORT_HTTP.equals(trp)) {
                         trsIn = (TransportInDescription)
                                 configctx.getAxisConfiguration().getTransportsIn().get(trp);
                         listenerManager.addListener(trsIn, false);


[axis-axis2-java-core] 35/38: AXIS2-5355 - Merged r1356080 to 1.5 branch.

Posted by bi...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

billblough pushed a commit to branch 1_5
in repository https://gitbox.apache.org/repos/asf/axis-axis2-java-core.git

commit afa04b28001641358afd6c96d62ee043316b5f6d
Author: Sagara Gunathunga <sa...@apache.org>
AuthorDate: Mon Jul 2 06:52:19 2012 +0000

    AXIS2-5355 - Merged r1356080 to 1.5 branch.
---
 modules/kernel/src/org/apache/axis2/description/AxisService.java       | 3 ++-
 .../transport/http/src/org/apache/axis2/transport/http/HTTPWorker.java | 3 ++-
 2 files changed, 4 insertions(+), 2 deletions(-)

diff --git a/modules/kernel/src/org/apache/axis2/description/AxisService.java b/modules/kernel/src/org/apache/axis2/description/AxisService.java
index 58f73cc..8866154 100644
--- a/modules/kernel/src/org/apache/axis2/description/AxisService.java
+++ b/modules/kernel/src/org/apache/axis2/description/AxisService.java
@@ -1260,9 +1260,10 @@ public class AxisService extends AxisDescription {
         if ((xsd != null) && (!"".equals(xsd))) {
             XmlSchema schema = (XmlSchema) schemaMappingtable.get(xsd);
             if (schema == null) {
-                int dotIndex = xsd.indexOf('.');
+                int dotIndex = xsd.lastIndexOf('.');
                 if (dotIndex > 0) {
                     String schemaKey = xsd.substring(0, dotIndex);
+                    schemaKey = schemaKey.replace("./" , "");
                     schema = (XmlSchema) schemaMappingtable.get(schemaKey);
                 }
             }
diff --git a/modules/transport/http/src/org/apache/axis2/transport/http/HTTPWorker.java b/modules/transport/http/src/org/apache/axis2/transport/http/HTTPWorker.java
index 4d30dea..186a110 100644
--- a/modules/transport/http/src/org/apache/axis2/transport/http/HTTPWorker.java
+++ b/modules/transport/http/src/org/apache/axis2/transport/http/HTTPWorker.java
@@ -161,9 +161,10 @@ public class HTTPWorker implements Worker {
                     Map schemaTable = service.getSchemaMappingTable();
                     XmlSchema schema = (XmlSchema) schemaTable.get(schemaName);
                     if (schema == null) {
-                        int dotIndex = schemaName.indexOf('.');
+                        int dotIndex = schemaName.lastIndexOf('.');
                         if (dotIndex > 0) {
                             String schemaKey = schemaName.substring(0,dotIndex);
+                            schemaKey = schemaKey.replace("./", "");
                             schema = (XmlSchema) schemaTable.get(schemaKey);
                         }
                     }


[axis-axis2-java-core] 32/38: AXIS2-5345 - Merged r1351218 to 1.5 branch.

Posted by bi...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

billblough pushed a commit to branch 1_5
in repository https://gitbox.apache.org/repos/asf/axis-axis2-java-core.git

commit 0b99cd88e2843942ac820f5a309b7c729dd0e547
Author: Sagara Gunathunga <sa...@apache.org>
AuthorDate: Mon Jun 18 07:28:48 2012 +0000

    AXIS2-5345 - Merged r1351218 to 1.5  branch.
---
 pom.xml           | 2 +-
 src/site/site.xml | 2 +-
 2 files changed, 2 insertions(+), 2 deletions(-)

diff --git a/pom.xml b/pom.xml
index 68ec16f..dbc6743 100644
--- a/pom.xml
+++ b/pom.xml
@@ -582,7 +582,7 @@
                 </plugin>
                 <plugin>
                     <artifactId>maven-site-plugin</artifactId>
-                    <version>2.1.1</version>
+                    <version>3.1</version>
                 </plugin>
             </plugins>
         </pluginManagement>
diff --git a/src/site/site.xml b/src/site/site.xml
index b461cf3..85e6b6d 100644
--- a/src/site/site.xml
+++ b/src/site/site.xml
@@ -67,7 +67,7 @@
             <item name="Reference Library" href="refLib.html" />
             <item name="Online Java Docs" href="api/index.html" />
         </menu>
-        <menu name="Get Involved" href="overview.html">
+        <menu name="Get Involved">
             <item name="Overview" href="overview.html" />
             <item name="Checkout the Source" href="svn.html" />
             <item name="Mailing Lists" href="mail-lists.html" />


[axis-axis2-java-core] 12/38: Merged r922828 to the 1.5 branch to be able to import axis2-kernel into Eclipse.

Posted by bi...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

billblough pushed a commit to branch 1_5
in repository https://gitbox.apache.org/repos/asf/axis-axis2-java-core.git

commit 783eae317a86e7f190fd53ebd3977c4c76d26843
Author: Andreas Veithen <ve...@apache.org>
AuthorDate: Fri Nov 11 11:49:13 2011 +0000

    Merged r922828 to the 1.5 branch to be able to import axis2-kernel into Eclipse.
---
 modules/kernel/pom.xml | 10 +++-------
 1 file changed, 3 insertions(+), 7 deletions(-)

diff --git a/modules/kernel/pom.xml b/modules/kernel/pom.xml
index 0e607bb..b14f94d 100644
--- a/modules/kernel/pom.xml
+++ b/modules/kernel/pom.xml
@@ -122,13 +122,6 @@
         </resources>
         <testResources>
             <testResource>
-                <targetPath>../test-resources</targetPath>
-                <directory>test-resources</directory>
-                <includes>
-                    <include>**/**</include>
-                </includes>
-            </testResource>
-            <testResource>
                 <directory>test-resources/deployment/ClasspathModule</directory>
                 <includes>
                     <include>**/**</include>
@@ -192,6 +185,9 @@
                         <phase>process-test-resources</phase>
                         <configuration>
                             <tasks unless="maven.test.skip">
+                                <copy todir="${project.build.directory}/test-resources">
+                                    <fileset dir="${basedir}/test-resources"/>
+                                </copy>
                                 <ant antfile="build.xml" inheritall="true" inheritrefs="true" dir="test-resources/deployment/service2" />
                                 <ant antfile="build.xml" inheritall="true" inheritrefs="true" dir="test-resources/deployment/echo" />
                                 <ant antfile="build.xml" inheritall="true" inheritrefs="true" dir="test-resources/deployment/invalidservice" />


[axis-axis2-java-core] 36/38: AXIS2-5360 - Merged r1358508 to 1.5 branch.

Posted by bi...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

billblough pushed a commit to branch 1_5
in repository https://gitbox.apache.org/repos/asf/axis-axis2-java-core.git

commit 3a1d4bddabfeefd71fa4619c337e26bc0f48caf4
Author: Sagara Gunathunga <sa...@apache.org>
AuthorDate: Sat Jul 7 06:17:13 2012 +0000

    AXIS2-5360 - Merged r1358508 to 1.5 branch.
---
 modules/kernel/src/org/apache/axis2/util/PrettyPrinter.java | 10 +++++-----
 1 file changed, 5 insertions(+), 5 deletions(-)

diff --git a/modules/kernel/src/org/apache/axis2/util/PrettyPrinter.java b/modules/kernel/src/org/apache/axis2/util/PrettyPrinter.java
index 440e000..d3004e3 100644
--- a/modules/kernel/src/org/apache/axis2/util/PrettyPrinter.java
+++ b/modules/kernel/src/org/apache/axis2/util/PrettyPrinter.java
@@ -47,7 +47,7 @@ public class PrettyPrinter {
         // If the user has set "axis2.jalopy=false" on the system property,
         // then just return back to caller
         String property = System.getProperty("axis2.jalopy");
-        if((property == null) || !JavaUtils.isTrueExplicitly(property)){
+        if((property != null) && !JavaUtils.isTrueExplicitly(property)){
             return;
         }
         PrintStream backupOutputStream = System.out;
@@ -55,7 +55,7 @@ public class PrettyPrinter {
         System.setOut(new PrintStream(new ByteArrayOutputStream()));
         System.setErr(new PrintStream(new ByteArrayOutputStream()));
         try {
-            Class clazzConfigurator = Loader.loadClass("org.apache.log4j.PropertyConfigurator");
+            Class<?> clazzConfigurator = Loader.loadClass("org.apache.log4j.PropertyConfigurator");
             Method configure = clazzConfigurator.getMethod("configure", new Class[]{Properties.class});
             Properties properties = new Properties();
             properties.setProperty("log4j.logger.de.hunsicker.jalopy.io",
@@ -63,7 +63,7 @@ public class PrettyPrinter {
             configure.invoke(null, new Object[]{properties});
 
             // Create an instance of the Jalopy bean
-            Class clazz = Loader.loadClass("de.hunsicker.jalopy.Jalopy");
+            Class<?> clazz = Loader.loadClass("de.hunsicker.jalopy.Jalopy");
             Object prettifier = clazz.newInstance();
 
             // Set the input file
@@ -74,11 +74,11 @@ public class PrettyPrinter {
             Method output = clazz.getMethod("setOutput", new Class[]{File.class});
             output.invoke(prettifier, new Object[]{file});
 
-            Class clazz2 = Loader.loadClass("de.hunsicker.jalopy.storage.Convention");
+            Class<?> clazz2 = Loader.loadClass("de.hunsicker.jalopy.storage.Convention");
             Method instance = clazz2.getMethod("getInstance", new Class[]{});
             Object settings = instance.invoke(null, new Object[]{});
 
-            Class clazz3 = Loader.loadClass("de.hunsicker.jalopy.storage.ConventionKeys");
+            Class<?> clazz3 = Loader.loadClass("de.hunsicker.jalopy.storage.ConventionKeys");
             Field field = clazz3.getField("COMMENT_FORMAT_MULTI_LINE");
             Object key = field.get(null);
             Method put = clazz2.getMethod("put", new Class[]{key.getClass(), String.class});


[axis-axis2-java-core] 30/38: Merged r1332587 to the 1.5 branch.

Posted by bi...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

billblough pushed a commit to branch 1_5
in repository https://gitbox.apache.org/repos/asf/axis-axis2-java-core.git

commit bbdf4b7ed5cc5c7b2eb31b97382e904a41230f93
Author: Sagara Gunathunga <sa...@apache.org>
AuthorDate: Wed May 23 09:10:07 2012 +0000

    Merged  r1332587  to the 1.5 branch.
---
 .../axis2/deployment/util/TempFileManager.java     | 29 ++++++++++++++--------
 1 file changed, 18 insertions(+), 11 deletions(-)

diff --git a/modules/kernel/src/org/apache/axis2/deployment/util/TempFileManager.java b/modules/kernel/src/org/apache/axis2/deployment/util/TempFileManager.java
index b26a272..3517a06 100644
--- a/modules/kernel/src/org/apache/axis2/deployment/util/TempFileManager.java
+++ b/modules/kernel/src/org/apache/axis2/deployment/util/TempFileManager.java
@@ -18,7 +18,12 @@
  */
 package org.apache.axis2.deployment.util;
 
-import java.io.*;
+
+import java.io.ByteArrayOutputStream;
+import java.io.File;
+import java.io.FileFilter;
+import java.io.IOException;
+import java.io.PrintStream;
 import java.util.logging.Level;
 import java.util.logging.Logger;
 
@@ -135,16 +140,18 @@ public class TempFileManager {
             throws IOException {
         // Select all the files
         File[] files = rootDir.listFiles();
-        for (File file : files) {
-            // If the file is a directory, we will
-            // recursively call delete on it.
-            if (file.isDirectory()) {
-                recursiveDelete(file);
-            } else {
-                // It is just a file so we are safe to
-                // delete it
-                if (!file.delete()) {
-                    throw new IOException("Could not delete: " + file.getAbsolutePath());
+        if (files != null) {
+            for (File file : files) {
+                // If the file is a directory, we will
+                // recursively call delete on it.
+                if (file.isDirectory()) {
+                    recursiveDelete(file);
+                } else {
+                    // It is just a file so we are safe to
+                    // delete it
+                    if (!file.delete()) {
+                        throw new IOException("Could not delete: " + file.getAbsolutePath());
+                    }
                 }
             }
         }


[axis-axis2-java-core] 23/38: Merged r1173869 and r1299356 to the 1.5 branch.

Posted by bi...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

billblough pushed a commit to branch 1_5
in repository https://gitbox.apache.org/repos/asf/axis-axis2-java-core.git

commit f163826867abe048602e8afe3ecdf5758f0cc3fd
Author: Andreas Veithen <ve...@apache.org>
AuthorDate: Sun Mar 11 14:22:20 2012 +0000

    Merged r1173869 and r1299356 to the 1.5 branch.
---
 .../adb/src/org/apache/axis2/databinding/utils/MultirefHelper.java  | 4 ++--
 .../test/org/apache/axis2/databinding/utils/MultirefHelperTest.java | 1 +
 .../apache/axis2/handlers/addressing/AddressingInFaultHandler.java  | 1 +
 .../jaxws/src/org/apache/axis2/jaxws/message/impl/XMLSpineImpl.java | 3 +++
 modules/saaj/src/org/apache/axis2/saaj/SOAPElementImpl.java         | 6 ++----
 5 files changed, 9 insertions(+), 6 deletions(-)

diff --git a/modules/adb/src/org/apache/axis2/databinding/utils/MultirefHelper.java b/modules/adb/src/org/apache/axis2/databinding/utils/MultirefHelper.java
index 073484d..80d631a 100644
--- a/modules/adb/src/org/apache/axis2/databinding/utils/MultirefHelper.java
+++ b/modules/adb/src/org/apache/axis2/databinding/utils/MultirefHelper.java
@@ -146,8 +146,8 @@ public class MultirefHelper {
             OMElement omElement = (OMElement)childs.next();
             OMAttribute id = omElement.getAttribute(new QName("id"));
             if (id != null) {
-                omElement.build();
-                elementMap.put(id.getAttributeValue(), omElement.detach());
+                childs.remove();
+                elementMap.put(id.getAttributeValue(), omElement);
             }
         }
         filledTable = true;
diff --git a/modules/adb/test/org/apache/axis2/databinding/utils/MultirefHelperTest.java b/modules/adb/test/org/apache/axis2/databinding/utils/MultirefHelperTest.java
index 74a2253..27b9561 100644
--- a/modules/adb/test/org/apache/axis2/databinding/utils/MultirefHelperTest.java
+++ b/modules/adb/test/org/apache/axis2/databinding/utils/MultirefHelperTest.java
@@ -111,6 +111,7 @@ public class MultirefHelperTest extends TestCase {
             OMElement omElement = null;
             for (Iterator iter = generatedElement.getChildElements();iter.hasNext();){
                 omElement = (OMElement) iter.next();
+                iter.remove();
                 soapEnvelope.getBody().addChild(omElement);
             }
 
diff --git a/modules/addressing/src/org/apache/axis2/handlers/addressing/AddressingInFaultHandler.java b/modules/addressing/src/org/apache/axis2/handlers/addressing/AddressingInFaultHandler.java
index 8efd4a5..4f4f682 100644
--- a/modules/addressing/src/org/apache/axis2/handlers/addressing/AddressingInFaultHandler.java
+++ b/modules/addressing/src/org/apache/axis2/handlers/addressing/AddressingInFaultHandler.java
@@ -70,6 +70,7 @@ public class AddressingInFaultHandler extends AbstractHandler implements Address
                     Iterator i = element.getChildElements();
                     while (i.hasNext()) {
                         OMElement detailElement = (OMElement)i.next();
+                        i.remove();
                         detail.addDetailEntry(detailElement);
                     }
                 }
diff --git a/modules/jaxws/src/org/apache/axis2/jaxws/message/impl/XMLSpineImpl.java b/modules/jaxws/src/org/apache/axis2/jaxws/message/impl/XMLSpineImpl.java
index 4040241..b43278c 100644
--- a/modules/jaxws/src/org/apache/axis2/jaxws/message/impl/XMLSpineImpl.java
+++ b/modules/jaxws/src/org/apache/axis2/jaxws/message/impl/XMLSpineImpl.java
@@ -457,6 +457,9 @@ class XMLSpineImpl implements XMLSpine {
             // the requested namespace/localPart
             if (om.getNamespace().getNamespaceURI().equals(namespace) &&
                 om.getLocalName().equals(localPart)) {
+                // _getBlockFromOMElement may replace the current element; move the iterator to the
+                // next element to avoid ConcurrentModificationException
+                it.hasNext();
                 Block block = _getBlockFromOMElement(om, context, blockFactory, false);
                 blocks.add(block);
             }
diff --git a/modules/saaj/src/org/apache/axis2/saaj/SOAPElementImpl.java b/modules/saaj/src/org/apache/axis2/saaj/SOAPElementImpl.java
index 5e1e293..b5293ae 100644
--- a/modules/saaj/src/org/apache/axis2/saaj/SOAPElementImpl.java
+++ b/modules/saaj/src/org/apache/axis2/saaj/SOAPElementImpl.java
@@ -518,10 +518,8 @@ public class SOAPElementImpl extends NodeImplEx implements SOAPElement {
         //We will get all the children and iteratively call the detach() on all of 'em.
         Iterator childIter = element.getChildElements();
         while (childIter.hasNext()) {
-            Object o = childIter.next();
-            if (o instanceof org.apache.axiom.om.OMNode) {
-                ((org.apache.axiom.om.OMNode)o).detach();
-            }
+            childIter.next();
+            childIter.remove();
         }
     }
 


[axis-axis2-java-core] 16/38: Merged r1231465 to the 1.5 branch.

Posted by bi...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

billblough pushed a commit to branch 1_5
in repository https://gitbox.apache.org/repos/asf/axis-axis2-java-core.git

commit c480fe37b6908a9b93205f0b8331b92749634bbb
Author: Sagara Gunathunga <sa...@apache.org>
AuthorDate: Sat Jan 14 09:07:40 2012 +0000

    Merged r1231465 to the 1.5 branch.
---
 .../userguide/clients/EchoNonBlockingClient.java   | 65 ++++++++++++++--------
 .../clients/EchoNonBlockingDualClient.java         | 63 +++++++++++++--------
 2 files changed, 82 insertions(+), 46 deletions(-)

diff --git a/modules/samples/userguide/src/userguide/clients/EchoNonBlockingClient.java b/modules/samples/userguide/src/userguide/clients/EchoNonBlockingClient.java
index cae78e6..ba47eeb 100644
--- a/modules/samples/userguide/src/userguide/clients/EchoNonBlockingClient.java
+++ b/modules/samples/userguide/src/userguide/clients/EchoNonBlockingClient.java
@@ -25,16 +25,15 @@ import org.apache.axis2.AxisFault;
 import org.apache.axis2.addressing.EndpointReference;
 import org.apache.axis2.client.Options;
 import org.apache.axis2.client.ServiceClient;
-import org.apache.axis2.client.async.AsyncResult;
-import org.apache.axis2.client.async.Callback;
+import org.apache.axis2.client.async.AxisCallback;
 
 /**
  * Sample for asynchronous single channel non-blocking service invocation.
- * Message Exchage Pattern IN-OUT
+ * Message Exchange Pattern IN-OUT
  */
 public class EchoNonBlockingClient {
     private static EndpointReference targetEPR = new EndpointReference("http://127.0.0.1:8080/axis2/services/MyService");
-
+ 
     public static void main(String[] args) {
         ServiceClient sender = null;
         try {
@@ -43,38 +42,58 @@ public class EchoNonBlockingClient {
             options.setTo(targetEPR);
             options.setAction("urn:echo");
 
-            //Callback to handle the response
-            Callback callback = new Callback() {
-                public void onComplete(AsyncResult result) {
-                    System.out.println(result.getResponseEnvelope());
-                }
-
-                public void onError(Exception e) {
-                    e.printStackTrace();
-                }
-            };
-
+            TestCallback axisCallback = new TestCallback("CallBack1") ;
+            
             //Non-Blocking Invocation
             sender = new ServiceClient();
             sender.setOptions(options);
-            sender.sendReceiveNonBlocking(payload, callback);
-
-            //Wait till the callback receives the response.
-            while (!callback.isComplete()) {
-                Thread.sleep(1000);
+            sender.sendReceiveNonBlocking(payload, axisCallback);
+            
+            while ( ! axisCallback.isComplete( ) ) {
+                Thread.sleep(100);
             }
 
-        } catch (AxisFault axisFault) {
-            axisFault.printStackTrace();
         } catch (Exception ex) {
             ex.printStackTrace();
         } finally {
             try {
                 sender.cleanup();
             } catch (AxisFault axisFault) {
-                //
+                axisFault.printStackTrace();
             }
         }
 
     }
+    
+    static class TestCallback implements AxisCallback {
+
+        private String name = null;
+        private boolean complete = false;
+        
+        public TestCallback (String name) {
+                this.name = name;
+        }
+
+        public void onError (Exception e) {
+                e.printStackTrace();
+        }
+
+        public void onComplete() {
+        	System.out.println( "Message transmission complete") ;
+            complete = true;
+        }
+        
+        public boolean isComplete() {
+            return complete;
+        }
+        
+        public void onMessage(org.apache.axis2.context.MessageContext arg0) {
+           System.out.println( "Call Back " + name + " got Result: " + arg0.getEnvelope() ) ;
+        }
+
+        public void onFault(org.apache.axis2.context.MessageContext arg0) {
+        	System.out.println( "Call Back " + name + " got Fault: " + arg0.getEnvelope() ) ;
+        }
+    }
+  
 }
diff --git a/modules/samples/userguide/src/userguide/clients/EchoNonBlockingDualClient.java b/modules/samples/userguide/src/userguide/clients/EchoNonBlockingDualClient.java
index 7f5a5ad..b13a331 100644
--- a/modules/samples/userguide/src/userguide/clients/EchoNonBlockingDualClient.java
+++ b/modules/samples/userguide/src/userguide/clients/EchoNonBlockingDualClient.java
@@ -23,13 +23,11 @@ package userguide.clients;
 import org.apache.axiom.om.OMElement;
 import org.apache.axis2.AxisFault;
 import org.apache.axis2.Constants;
+import org.apache.axis2.addressing.AddressingConstants;
 import org.apache.axis2.addressing.EndpointReference;
 import org.apache.axis2.client.Options;
 import org.apache.axis2.client.ServiceClient;
-import org.apache.axis2.client.async.AsyncResult;
-import org.apache.axis2.client.async.Callback;
-
-import javax.xml.namespace.QName;
+import org.apache.axis2.client.async.AxisCallback;
 
 /**
  * Sample for asynchronous dual channel non-blocking service invocation.
@@ -51,40 +49,59 @@ public class EchoNonBlockingDualClient {
             options.setUseSeparateListener(true);
             options.setAction("urn:echo");  // this is the action mapping we put within the service.xml
 
-            //Callback to handle the response
-            Callback callback = new Callback() {
-                public void onComplete(AsyncResult result) {
-                    System.out.println(result.getResponseEnvelope());
-                }
-
-                public void onError(Exception e) {
-                    e.printStackTrace();
-                }
-            };
-
+            TestCallback axisCallback = new TestCallback("CallBack1") ;
+                        
             //Non-Blocking Invocation
             sender = new ServiceClient();
             sender.engageModule(Constants.MODULE_ADDRESSING);
             sender.setOptions(options);
-            sender.sendReceiveNonBlocking(payload, callback);
+            sender.sendReceiveNonBlocking(payload, axisCallback);
 
             //Wait till the callback receives the response.
-            while (!callback.isComplete()) {
-                Thread.sleep(1000);
+            while ( ! axisCallback.isComplete( ) ) {
+                Thread.sleep(100);
             }
-            //Need to close the Client Side Listener.
-
-        } catch (AxisFault axisFault) {
-            axisFault.printStackTrace();
+            
         } catch (Exception ex) {
             ex.printStackTrace();
         } finally {
             try {
                 sender.cleanup();
             } catch (AxisFault axisFault) {
-                //have to ignore this
+                axisFault.printStackTrace();
             }
+        	
+        }
+    }
+    
+    static class TestCallback implements AxisCallback {
+
+        private String name = null;
+        private boolean complete = false;
+        
+        public TestCallback (String name) {
+                this.name = name;
         }
 
+        public void onError (Exception e) {
+                e.printStackTrace();
+        }
+
+        public void onComplete() {
+        	System.out.println( "Message transmission complete") ;
+            complete = true;
+        }
+        
+        public boolean isComplete() {
+            return complete;
+        }
+        
+        public void onMessage(org.apache.axis2.context.MessageContext arg0) {
+           System.out.println( "Call Back " + name + " got Result: " + arg0.getEnvelope() ) ;
+        }
+
+        public void onFault(org.apache.axis2.context.MessageContext arg0) {
+        	System.out.println( "Call Back " + name + " got Fault: " + arg0.getEnvelope() ) ;
+        }
     }
 }


[axis-axis2-java-core] 27/38: Merged r1326968 to the 1.5 branch.

Posted by bi...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

billblough pushed a commit to branch 1_5
in repository https://gitbox.apache.org/repos/asf/axis-axis2-java-core.git

commit 9997c20d9b6b2ffd322a85a822197bcef7d67314
Author: Sagara Gunathunga <sa...@apache.org>
AuthorDate: Tue Apr 17 07:48:03 2012 +0000

    Merged r1326968 to the 1.5 branch.
---
 legal/apache-mime4j-core-LICENSE.txt | 203 +++++++++++++++++++++++++++++++++++
 1 file changed, 203 insertions(+)

diff --git a/legal/apache-mime4j-core-LICENSE.txt b/legal/apache-mime4j-core-LICENSE.txt
new file mode 100644
index 0000000..6b0b127
--- /dev/null
+++ b/legal/apache-mime4j-core-LICENSE.txt
@@ -0,0 +1,203 @@
+
+                                 Apache License
+                           Version 2.0, January 2004
+                        http://www.apache.org/licenses/
+
+   TERMS AND CONDITIONS FOR USE, REPRODUCTION, AND DISTRIBUTION
+
+   1. Definitions.
+
+      "License" shall mean the terms and conditions for use, reproduction,
+      and distribution as defined by Sections 1 through 9 of this document.
+
+      "Licensor" shall mean the copyright owner or entity authorized by
+      the copyright owner that is granting the License.
+
+      "Legal Entity" shall mean the union of the acting entity and all
+      other entities that control, are controlled by, or are under common
+      control with that entity. For the purposes of this definition,
+      "control" means (i) the power, direct or indirect, to cause the
+      direction or management of such entity, whether by contract or
+      otherwise, or (ii) ownership of fifty percent (50%) or more of the
+      outstanding shares, or (iii) beneficial ownership of such entity.
+
+      "You" (or "Your") shall mean an individual or Legal Entity
+      exercising permissions granted by this License.
+
+      "Source" form shall mean the preferred form for making modifications,
+      including but not limited to software source code, documentation
+      source, and configuration files.
+
+      "Object" form shall mean any form resulting from mechanical
+      transformation or translation of a Source form, including but
+      not limited to compiled object code, generated documentation,
+      and conversions to other media types.
+
+      "Work" shall mean the work of authorship, whether in Source or
+      Object form, made available under the License, as indicated by a
+      copyright notice that is included in or attached to the work
+      (an example is provided in the Appendix below).
+
+      "Derivative Works" shall mean any work, whether in Source or Object
+      form, that is based on (or derived from) the Work and for which the
+      editorial revisions, annotations, elaborations, or other modifications
+      represent, as a whole, an original work of authorship. For the purposes
+      of this License, Derivative Works shall not include works that remain
+      separable from, or merely link (or bind by name) to the interfaces of,
+      the Work and Derivative Works thereof.
+
+      "Contribution" shall mean any work of authorship, including
+      the original version of the Work and any modifications or additions
+      to that Work or Derivative Works thereof, that is intentionally
+      submitted to Licensor for inclusion in the Work by the copyright owner
+      or by an individual or Legal Entity authorized to submit on behalf of
+      the copyright owner. For the purposes of this definition, "submitted"
+      means any form of electronic, verbal, or written communication sent
+      to the Licensor or its representatives, including but not limited to
+      communication on electronic mailing lists, source code control systems,
+      and issue tracking systems that are managed by, or on behalf of, the
+      Licensor for the purpose of discussing and improving the Work, but
+      excluding communication that is conspicuously marked or otherwise
+      designated in writing by the copyright owner as "Not a Contribution."
+
+      "Contributor" shall mean Licensor and any individual or Legal Entity
+      on behalf of whom a Contribution has been received by Licensor and
+      subsequently incorporated within the Work.
+
+   2. Grant of Copyright License. Subject to the terms and conditions of
+      this License, each Contributor hereby grants to You a perpetual,
+      worldwide, non-exclusive, no-charge, royalty-free, irrevocable
+      copyright license to reproduce, prepare Derivative Works of,
+      publicly display, publicly perform, sublicense, and distribute the
+      Work and such Derivative Works in Source or Object form.
+
+   3. Grant of Patent License. Subject to the terms and conditions of
+      this License, each Contributor hereby grants to You a perpetual,
+      worldwide, non-exclusive, no-charge, royalty-free, irrevocable
+      (except as stated in this section) patent license to make, have made,
+      use, offer to sell, sell, import, and otherwise transfer the Work,
+      where such license applies only to those patent claims licensable
+      by such Contributor that are necessarily infringed by their
+      Contribution(s) alone or by combination of their Contribution(s)
+      with the Work to which such Contribution(s) was submitted. If You
+      institute patent litigation against any entity (including a
+      cross-claim or counterclaim in a lawsuit) alleging that the Work
+      or a Contribution incorporated within the Work constitutes direct
+      or contributory patent infringement, then any patent licenses
+      granted to You under this License for that Work shall terminate
+      as of the date such litigation is filed.
+
+   4. Redistribution. You may reproduce and distribute copies of the
+      Work or Derivative Works thereof in any medium, with or without
+      modifications, and in Source or Object form, provided that You
+      meet the following conditions:
+
+      (a) You must give any other recipients of the Work or
+          Derivative Works a copy of this License; and
+
+      (b) You must cause any modified files to carry prominent notices
+          stating that You changed the files; and
+
+      (c) You must retain, in the Source form of any Derivative Works
+          that You distribute, all copyright, patent, trademark, and
+          attribution notices from the Source form of the Work,
+          excluding those notices that do not pertain to any part of
+          the Derivative Works; and
+
+      (d) If the Work includes a "NOTICE" text file as part of its
+          distribution, then any Derivative Works that You distribute must
+          include a readable copy of the attribution notices contained
+          within such NOTICE file, excluding those notices that do not
+          pertain to any part of the Derivative Works, in at least one
+          of the following places: within a NOTICE text file distributed
+          as part of the Derivative Works; within the Source form or
+          documentation, if provided along with the Derivative Works; or,
+          within a display generated by the Derivative Works, if and
+          wherever such third-party notices normally appear. The contents
+          of the NOTICE file are for informational purposes only and
+          do not modify the License. You may add Your own attribution
+          notices within Derivative Works that You distribute, alongside
+          or as an addendum to the NOTICE text from the Work, provided
+          that such additional attribution notices cannot be construed
+          as modifying the License.
+
+      You may add Your own copyright statement to Your modifications and
+      may provide additional or different license terms and conditions
+      for use, reproduction, or distribution of Your modifications, or
+      for any such Derivative Works as a whole, provided Your use,
+      reproduction, and distribution of the Work otherwise complies with
+      the conditions stated in this License.
+
+   5. Submission of Contributions. Unless You explicitly state otherwise,
+      any Contribution intentionally submitted for inclusion in the Work
+      by You to the Licensor shall be under the terms and conditions of
+      this License, without any additional terms or conditions.
+      Notwithstanding the above, nothing herein shall supersede or modify
+      the terms of any separate license agreement you may have executed
+      with Licensor regarding such Contributions.
+
+   6. Trademarks. This License does not grant permission to use the trade
+      names, trademarks, service marks, or product names of the Licensor,
+      except as required for reasonable and customary use in describing the
+      origin of the Work and reproducing the content of the NOTICE file.
+
+   7. Disclaimer of Warranty. Unless required by applicable law or
+      agreed to in writing, Licensor provides the Work (and each
+      Contributor provides its Contributions) on an "AS IS" BASIS,
+      WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or
+      implied, including, without limitation, any warranties or conditions
+      of TITLE, NON-INFRINGEMENT, MERCHANTABILITY, or FITNESS FOR A
+      PARTICULAR PURPOSE. You are solely responsible for determining the
+      appropriateness of using or redistributing the Work and assume any
+      risks associated with Your exercise of permissions under this License.
+
+   8. Limitation of Liability. In no event and under no legal theory,
+      whether in tort (including negligence), contract, or otherwise,
+      unless required by applicable law (such as deliberate and grossly
+      negligent acts) or agreed to in writing, shall any Contributor be
+      liable to You for damages, including any direct, indirect, special,
+      incidental, or consequential damages of any character arising as a
+      result of this License or out of the use or inability to use the
+      Work (including but not limited to damages for loss of goodwill,
+      work stoppage, computer failure or malfunction, or any and all
+      other commercial damages or losses), even if such Contributor
+      has been advised of the possibility of such damages.
+
+   9. Accepting Warranty or Additional Liability. While redistributing
+      the Work or Derivative Works thereof, You may choose to offer,
+      and charge a fee for, acceptance of support, warranty, indemnity,
+      or other liability obligations and/or rights consistent with this
+      License. However, in accepting such obligations, You may act only
+      on Your own behalf and on Your sole responsibility, not on behalf
+      of any other Contributor, and only if You agree to indemnify,
+      defend, and hold each Contributor harmless for any liability
+      incurred by, or claims asserted against, such Contributor by reason
+      of your accepting any such warranty or additional liability.
+
+   END OF TERMS AND CONDITIONS
+
+   APPENDIX: How to apply the Apache License to your work.
+
+      To apply the Apache License to your work, attach the following
+      boilerplate notice, with the fields enclosed by brackets "[]"
+      replaced with your own identifying information. (Don't include
+      the brackets!)  The text should be enclosed in the appropriate
+      comment syntax for the file format. We also recommend that a
+      file or class name and description of purpose be included on the
+      same "printed page" as the copyright notice for easier
+      identification within third-party archives.
+
+   Copyright [yyyy] [name of copyright owner]
+
+   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.
+


[axis-axis2-java-core] 04/38: Merged r1150055 to the 1.5 branch to ensure compatibility with Axiom 1.2.13.

Posted by bi...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

billblough pushed a commit to branch 1_5
in repository https://gitbox.apache.org/repos/asf/axis-axis2-java-core.git

commit 1147e979bdc01b398ec1d7cda296b7e466ad6f0e
Author: Andreas Veithen <ve...@apache.org>
AuthorDate: Thu Sep 29 21:57:08 2011 +0000

    Merged r1150055 to the 1.5 branch to ensure compatibility with Axiom 1.2.13.
---
 .../src/org/apache/axis2/scripting/ScriptMessageContext.java   | 10 +++++++++-
 1 file changed, 9 insertions(+), 1 deletion(-)

diff --git a/modules/scripting/src/org/apache/axis2/scripting/ScriptMessageContext.java b/modules/scripting/src/org/apache/axis2/scripting/ScriptMessageContext.java
index 30c9d86..2e5a2f3 100644
--- a/modules/scripting/src/org/apache/axis2/scripting/ScriptMessageContext.java
+++ b/modules/scripting/src/org/apache/axis2/scripting/ScriptMessageContext.java
@@ -19,6 +19,9 @@
 
 package org.apache.axis2.scripting;
 
+import java.util.Iterator;
+
+import org.apache.axiom.soap.SOAPBody;
 import org.apache.axis2.addressing.EndpointReference;
 import org.apache.axis2.context.MessageContext;
 import org.apache.axis2.scripting.convertors.OMElementConvertor;
@@ -59,7 +62,12 @@ public class ScriptMessageContext extends MessageContext {
      * @throws XMLStreamException
      */
     public void setPayloadXML(Object payload) {
-        mc.getEnvelope().getBody().setFirstChild(convertor.fromScript(payload));
+        SOAPBody body = mc.getEnvelope().getBody();
+        for (Iterator it = body.getChildren(); it.hasNext(); ) {
+            it.next();
+            it.remove();
+        }
+        body.addChild(convertor.fromScript(payload));
     }
 
     /**


[axis-axis2-java-core] 11/38: Merged r922830 to the 1.5 branch to set up svn:ignore for the axis2-kernel module.

Posted by bi...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

billblough pushed a commit to branch 1_5
in repository https://gitbox.apache.org/repos/asf/axis-axis2-java-core.git

commit 8f3d0ceb594c17a08863dc396c0dc13a87c3f176
Author: Andreas Veithen <ve...@apache.org>
AuthorDate: Fri Nov 11 11:35:25 2011 +0000

    Merged r922830 to the 1.5 branch to set up svn:ignore for the axis2-kernel module.


[axis-axis2-java-core] 34/38: AXIS2-5348 - Merged r1352413 to 1.5 branch.

Posted by bi...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

billblough pushed a commit to branch 1_5
in repository https://gitbox.apache.org/repos/asf/axis-axis2-java-core.git

commit 8fa0853912bbbb29d51370087c1fa98eb74a2b2d
Author: Sagara Gunathunga <sa...@apache.org>
AuthorDate: Thu Jun 21 06:35:00 2012 +0000

    AXIS2-5348 - Merged r1352413 to 1.5 branch.
---
 modules/addressing/src/META-INF/module.xml         |  5 +-
 .../axis2/handlers/addressing/Addressing.java      | 59 ++++++++++++++++++++++
 2 files changed, 63 insertions(+), 1 deletion(-)

diff --git a/modules/addressing/src/META-INF/module.xml b/modules/addressing/src/META-INF/module.xml
index bd05f7a..0fd6ff5 100644
--- a/modules/addressing/src/META-INF/module.xml
+++ b/modules/addressing/src/META-INF/module.xml
@@ -17,7 +17,7 @@
   ~ under the License.
   -->
 
-<module name="addressing">
+<module name="addressing" class="org.apache.axis2.handlers.addressing.Addressing">
     <Description>This is the WS-Addressing implementation on Axis2, supporting the WS-Addressing 1.0 Recommendation, as well as the Submission version (2004/08).</Description>
     <InFlow>
         <handler name="AddressingInHandler" class="org.apache.axis2.handlers.addressing.AddressingInHandler">
@@ -50,4 +50,7 @@
         </handler>
         <!-- AddressingValidationHandler not present on the INfaultflow so that we don't get faults bouncing around forever -->
     </InFaultFlow>
+    
+    <supported-policy-namespaces namespaces="http://www.w3.org/2007/05/addressing/metadata"/>
+     
 </module>
diff --git a/modules/addressing/src/org/apache/axis2/handlers/addressing/Addressing.java b/modules/addressing/src/org/apache/axis2/handlers/addressing/Addressing.java
new file mode 100644
index 0000000..047e8e1
--- /dev/null
+++ b/modules/addressing/src/org/apache/axis2/handlers/addressing/Addressing.java
@@ -0,0 +1,59 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements. See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership. The ASF licenses this file
+ * to you 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.axis2.handlers.addressing;
+
+import org.apache.axis2.AxisFault;
+import org.apache.axis2.addressing.AddressingConstants;
+import org.apache.axis2.context.ConfigurationContext;
+import org.apache.axis2.description.AxisDescription;
+import org.apache.axis2.description.AxisModule;
+import org.apache.axis2.modules.Module;
+import org.apache.neethi.Assertion;
+import org.apache.neethi.Policy;
+
+/**
+ * The Class Addressing implements Module interface.
+ * 
+ * @since 1.5.7, 1.6.3, 1.7.0
+ */
+public class Addressing implements Module {
+
+    public void init(ConfigurationContext configContext, AxisModule module) throws AxisFault {
+    }
+
+    public void engageNotify(AxisDescription axisDescription) throws AxisFault {
+    }
+
+    public boolean canSupportAssertion(Assertion assertion) {
+        String ns = assertion.getName().getNamespaceURI();
+        // Addressing module can handle WS-Addressing Metadata 1.0
+        if (ns != null && AddressingConstants.Final.WSAM_NAMESPACE.equals(ns)) {
+            return true;
+        }
+        return false;
+    }
+
+    public void applyPolicy(Policy policy, AxisDescription axisDescription) throws AxisFault {
+    }
+
+    public void shutdown(ConfigurationContext configurationContext) throws AxisFault {
+    }
+
+}