You are viewing a plain text version of this content. The canonical link for it is here.
Posted to java-dev@axis.apache.org by wo...@apache.org on 2008/03/03 19:48:24 UTC

svn commit: r633234 [13/24] - in /webservices/axis2/trunk/java: ./ modules/jaxws-integration/ modules/jaxws-integration/test/ modules/jaxws-integration/test/client/ modules/jaxws-integration/test/org/ modules/jaxws-integration/test/org/apache/ modules/...

Added: webservices/axis2/trunk/java/modules/jaxws-integration/test/org/apache/axis2/jaxws/proxy/AsyncCallback.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/jaxws-integration/test/org/apache/axis2/jaxws/proxy/AsyncCallback.java?rev=633234&view=auto
==============================================================================
--- webservices/axis2/trunk/java/modules/jaxws-integration/test/org/apache/axis2/jaxws/proxy/AsyncCallback.java (added)
+++ webservices/axis2/trunk/java/modules/jaxws-integration/test/org/apache/axis2/jaxws/proxy/AsyncCallback.java Mon Mar  3 10:47:38 2008
@@ -0,0 +1,63 @@
+/*
+ * 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.jaxws.proxy;
+
+import java.util.concurrent.ExecutionException;
+
+import javax.xml.ws.AsyncHandler;
+import javax.xml.ws.Response;
+
+import org.test.proxy.doclitwrapped.ReturnType;
+import org.apache.axis2.jaxws.TestLogger;
+
+/**
+ *
+ */
+public class AsyncCallback implements AsyncHandler {
+
+    public AsyncCallback() {
+        super();
+    }
+
+    /* (non-Javadoc)
+     * @see javax.xml.ws.AsyncHandler#handleResponse(javax.xml.ws.Response)
+     */
+    public void handleResponse(Response response) {
+        try{
+            Object obj = response.get();
+            if(obj instanceof ReturnType){
+                ReturnType type = (ReturnType)obj;
+                TestLogger.logger.debug(">>Return String = " + type.getReturnStr());
+                return;
+            }
+            if(obj instanceof org.test.proxy.doclitnonwrapped.ReturnType){
+                org.test.proxy.doclitnonwrapped.ReturnType returnType = (org.test.proxy.doclitnonwrapped.ReturnType)obj;
+                TestLogger.logger.debug(">>Return String = " + returnType.getReturnStr());
+                return;
+            }
+            TestLogger.logger.debug("Response.get should have been ReturnType");
+            
+        }catch(ExecutionException e){
+            e.printStackTrace();
+        }catch(InterruptedException e){
+            e.printStackTrace();
+        }
+    }
+
+}

Added: webservices/axis2/trunk/java/modules/jaxws-integration/test/org/apache/axis2/jaxws/proxy/GorillaDLWProxyTests.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/jaxws-integration/test/org/apache/axis2/jaxws/proxy/GorillaDLWProxyTests.java?rev=633234&view=auto
==============================================================================
--- webservices/axis2/trunk/java/modules/jaxws-integration/test/org/apache/axis2/jaxws/proxy/GorillaDLWProxyTests.java (added)
+++ webservices/axis2/trunk/java/modules/jaxws-integration/test/org/apache/axis2/jaxws/proxy/GorillaDLWProxyTests.java Mon Mar  3 10:47:38 2008
@@ -0,0 +1,406 @@
+/*
+ * 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.jaxws.proxy;
+
+import java.io.File;
+import java.net.MalformedURLException;
+import java.net.URL;
+import java.util.ArrayList;
+import java.util.List;
+
+import javax.xml.bind.JAXBContext;
+import javax.xml.bind.JAXBElement;
+import javax.xml.bind.Marshaller;
+import javax.xml.namespace.QName;
+import javax.xml.ws.BindingProvider;
+import javax.xml.ws.Dispatch;
+import javax.xml.ws.Service;
+
+import junit.framework.TestCase;
+import org.apache.axis2.jaxws.proxy.gorilla_dlw.sei.GorillaInterface;
+import org.apache.axis2.jaxws.TestLogger;
+
+public class GorillaDLWProxyTests extends TestCase {
+
+    private QName serviceName = new QName(
+            "http://org.apache.axis2.jaxws.proxy.gorilla_dlw", "GorillaService");
+    private String axisEndpoint = "http://localhost:6060/axis2/services/GorillaService.GorillaProxyImplPort";
+    private QName portName = new QName("http://org.apache.axis2.jaxws.proxy.rpclit",
+            "GorillaPort");
+    private String wsdlLocation = System.getProperty("basedir",".")+"/"+"test/org/apache/axis2/jaxws/proxy/gorilla_dlw/META-INF/gorilla_dlw.wsdl";
+    
+    /**
+     * Utility method to get the proxy
+     * @return GorillaInterface proxy
+     * @throws MalformedURLException
+     */
+    public GorillaInterface getProxy() throws MalformedURLException {
+        File wsdl= new File(wsdlLocation); 
+        URL wsdlUrl = wsdl.toURL(); 
+        Service service = Service.create(null, serviceName);
+        Object proxy =service.getPort(portName, GorillaInterface.class);
+        BindingProvider p = (BindingProvider)proxy; 
+        p.getRequestContext().put(BindingProvider.ENDPOINT_ADDRESS_PROPERTY,axisEndpoint);
+        
+        return (GorillaInterface)proxy;
+    }
+    
+    /**
+     * Utility Method to get a Dispatch<String>
+     * @return
+     * @throws MalformedURLException
+     */
+    public Dispatch<String> getDispatch() throws MalformedURLException {
+        File wsdl= new File(wsdlLocation); 
+        URL wsdlUrl = wsdl.toURL(); 
+        Service service = Service.create(null, serviceName);
+        service.addPort(portName, null, axisEndpoint);
+        Dispatch<String> dispatch = service.createDispatch(portName, String.class, Service.Mode.PAYLOAD);
+        return dispatch;
+    }
+    
+    /**
+     * Simple test that ensures that we can echo a string.
+     * If this test fails, it usually means that there are connection
+     * problems or deploy problems.
+     */
+    public void testEchoString() throws Exception {
+        try{ 
+            GorillaInterface proxy = getProxy();
+            
+            // Straight Forward Test
+            String request = "Hello World";
+           
+            String response = proxy.echoString(request);
+            assertTrue(response != null);
+            assertEquals(response, request);
+            
+        }catch(Exception e){ 
+            e.printStackTrace(); 
+            fail("Exception received" + e);
+        }
+    }
+    
+    /**
+     * Tests that we can echo a null
+     */
+    public void testEchoStringNull() throws Exception {
+        try{ 
+            GorillaInterface proxy = getProxy();
+            String request = null;  // Null is an appropriate input
+           
+            String response = proxy.echoString(request);
+            assertTrue(response == null);
+        }catch(Exception e){ 
+            e.printStackTrace(); 
+            fail("Exception received" + e);
+        }
+    }
+    
+    /**
+     * Testing of StringList (xsd:list of string)
+     */
+    public void testEchoStringList() throws Exception {
+        try{ 
+            GorillaInterface proxy = getProxy();
+            
+            // Test sending Hello World
+            List<String> request1 = new ArrayList<String>();
+            request1.add("Hello");
+            request1.add("World");
+            List<String> response1 = proxy.echoStringList(request1);
+            assertTrue(response1 != null);
+            assertTrue(compareLists(request1, response1));
+            
+            // Test with empty list
+            List<String> request2 = new ArrayList<String>();
+            List<String> response2 = proxy.echoStringList(request2);
+            assertTrue(response2 != null);
+            assertTrue(compareLists(request2, response2));
+            
+            // Test with null
+            // Note that the response will be an empty array because
+            // the JAXB bean will never represent List<String> as a null.  This is expected.
+            List<String> request3 = null;
+            List<String> response3 = proxy.echoStringList(request3);
+            assertTrue(response3 != null && response3.size() == 0);
+            
+            // Test sending Hello null World
+            // Note that the null is purged by JAXB.  This is expected.
+            List<String> request4 = new ArrayList<String>();
+            request4.add("Hello");
+            request4.add(null);
+            request4.add("World");
+            List<String> response4 = proxy.echoStringList(request4);
+            assertTrue(response4!= null);
+            assertTrue(compareLists(request1, response4));  // Response 4 should be the same as Request 1
+            
+            // Test sending "Hello World"
+            // Note that the Hello World is divided into two items.
+            // This is due to the xsd:list serialization. This is expected.
+            List<String> request5 = new ArrayList<String>();
+            request5.add("Hello World");
+            List<String> response5 = proxy.echoStringList(request5);
+            assertTrue(response5!= null);
+            assertTrue(compareLists(request1, response5)); // Response 5 should be the same as Request 1
+        }catch(Exception e){ 
+            e.printStackTrace(); 
+            fail("Exception received" + e);
+        }
+    }
+    
+    /**
+     * Testing of StringList (xsd:list of string)
+     * SEI is mapped to String[] instead of List<String>
+     */
+    public void testEchoStringListAlt() throws Exception {
+        try{ 
+            GorillaInterface proxy = getProxy();
+            
+            // Test sending Hello World
+            String[] request1 = new String[] {"Hello", "World"};
+            String[] response1 = proxy.echoStringListAlt(request1);
+            assertTrue(response1 != null);
+            assertTrue(compareArrays(request1, response1));
+            
+            // Test with empty array
+            String[] request2 = new String[] {};
+            String[] response2 = proxy.echoStringListAlt(request2);
+            assertTrue(response2 != null);
+            assertTrue(compareArrays(request2, response2));
+            
+            // Test with null
+            // Note that the response will be an empty array because
+            // the JAXB bean will never represent List<String> as a null.  This is expected.
+            String[] request3 = null;
+            String[] response3 = proxy.echoStringListAlt(request3);
+            assertTrue(response3 != null && response3.length == 0);
+            
+            // Test sending Hello null World
+            // Note that the null is purged by JAXB.  This is expected.
+            String[] request4 = new String[] {"Hello", null, "World"};
+            String[] response4 = proxy.echoStringListAlt(request4);
+            assertTrue(response4!= null);
+            assertTrue(compareArrays(request1, response4));  // Response 4 should be the same as Request 1
+            
+            // Test sending "Hello World"
+            // Note that the Hello World is divided into two items.
+            // This is due to the xsd:list serialization. This is expected.
+            String[] request5 = new String[] {"Hello World"};
+            String[] response5 = proxy.echoStringListAlt(request5);
+            assertTrue(response5!= null);
+            assertTrue(compareArrays(request1, response5)); // Response 5 should be the same as Request 1
+        }catch(Exception e){ 
+            e.printStackTrace(); 
+            fail("Exception received" + e);
+        }
+    }
+    
+    /**
+     * Test of String Array (string maxOccurs=unbounded)
+     * @throws Exception
+     */
+    public void testEchoIndexedStringArray() throws Exception {
+        try{ 
+            GorillaInterface proxy = getProxy();
+            
+            // Test sending Hello World
+            List<String> request1 = new ArrayList<String>();
+            request1.add("Hello");
+            request1.add("World");
+            List<String> response1 = proxy.echoIndexedStringArray(request1);
+            assertTrue(response1 != null);
+            assertTrue(compareLists(request1, response1));
+            
+            // Test with empty list
+            List<String> request2 = new ArrayList<String>();
+            List<String> response2 = proxy.echoIndexedStringArray(request2);
+            assertTrue(response2 != null);
+            assertTrue(compareLists(request2, response2));
+            
+            // Test with null
+            // Note that the response will be an empty array because
+            // the JAXB bean will never represent List<String> as a null.  This is expected.
+            List<String> request3 = null;
+            List<String> response3 = proxy.echoIndexedStringArray(request3);
+            assertTrue(response3 != null && response3.size() == 0);
+            
+            // Test sending Hello null World
+            // Note that the null is preserved and the request and response
+            // are the same..note that this is different than the xsd:list processing (see testStringList above)
+            // This is expected.
+            List<String> request4 = new ArrayList<String>();
+            request4.add("Hello");
+            request4.add(null);
+            request4.add("World");
+            List<String> response4 = proxy.echoIndexedStringArray(request4);
+            assertTrue(response4!= null);
+            assertTrue(compareLists(request4, response4));  // Response 4 should be the same as Request 1
+            
+            // Test sending "Hello World"
+            // Note that the Hello World remains one item.
+            List<String> request5 = new ArrayList<String>();
+            request5.add("Hello World");
+            List<String> response5 = proxy.echoIndexedStringArray(request5);
+            assertTrue(response5!= null);
+            assertTrue(compareLists(request5, response5)); // Response 5 should be the same as Request 1
+        }catch(Exception e){ 
+            e.printStackTrace(); 
+            fail("Exception received" + e);
+        }
+    }
+    
+    /**
+     * Test of String Array (string maxOccurs=unbounded)
+     * @throws Exception
+     */
+    public void testEchoStringArray() throws Exception {
+        try{ 
+            GorillaInterface proxy = getProxy();
+            
+            // Test sending Hello World
+            List<String> request1 = new ArrayList<String>();
+            request1.add("Hello");
+            request1.add("World");
+            List<String> response1 = proxy.echoStringArray(request1);
+            assertTrue(response1 != null);
+            assertTrue(compareLists(request1, response1));
+            
+            // Test with empty list
+            List<String> request2 = new ArrayList<String>();
+            List<String> response2 = proxy.echoStringArray(request2);
+            assertTrue(response2 != null);
+            assertTrue(compareLists(request2, response2));
+            
+            // Test with null
+            // Note that the response will be an empty array because
+            // the JAXB bean will never represent List<String> as a null.  This is expected.
+            List<String> request3 = null;
+            List<String> response3 = proxy.echoStringArray(request3);
+            assertTrue(response3 != null && response3.size() == 0);
+            
+            // Test sending Hello null World
+            // Note that the null is preserved and the request and response
+            // are the same..note that this is different than the xsd:list processing (see testStringList above)
+            // This is expected.
+            List<String> request4 = new ArrayList<String>();
+            request4.add("Hello");
+            request4.add(null);
+            request4.add("World");
+            List<String> response4 = proxy.echoStringArray(request4);
+            assertTrue(response4!= null);
+            assertTrue(compareLists(request4, response4));  // Response 4 should be the same as Request 1
+            
+            // Test sending "Hello World"
+            // Note that the Hello World remains one item.
+            List<String> request5 = new ArrayList<String>();
+            request5.add("Hello World");
+            List<String> response5 = proxy.echoStringArray(request5);
+            assertTrue(response5!= null);
+            assertTrue(compareLists(request5, response5)); // Response 5 should be the same as Request 1
+        }catch(Exception e){ 
+            e.printStackTrace(); 
+            fail("Exception received" + e);
+        }
+    }
+    
+    /**
+     * Test of String Array (string maxOccurs=unbounded) which is mapped to String[]
+     * @throws Exception
+     */
+    public void testEchoStringArrayAlt() throws Exception {
+        try{ 
+            GorillaInterface proxy = getProxy();
+            
+            // Test sending Hello World
+            String[] request1 = new String[] {"Hello", "World"};
+            String[] response1 = proxy.echoStringArrayAlt(request1);
+            assertTrue(response1 != null);
+            assertTrue(compareArrays(request1, response1));
+            
+            // Test with empty list
+            String[] request2 = new String[] {};
+            String[] response2 = proxy.echoStringArrayAlt(request2);
+            assertTrue(response2 != null);
+            assertTrue(compareArrays(request2, response2));
+            
+            // Test with null
+            // Note that the response will be an empty array because
+            // the JAXB bean will never represent List<String> as a null.  This is expected.
+            String[] request3 = null;
+            String[] response3 = proxy.echoStringArrayAlt(request3);
+            assertTrue(response3 != null && response3.length == 0);
+            
+            // Test sending Hello null World
+            // Note that the null is preserved and the request and response
+            // are the same..note that this is different than the xsd:list processing (see testStringList above)
+            // This is expected.
+            String[] request4 = new String[] {"Hello", null, "World"};
+            String[] response4 = proxy.echoStringArrayAlt(request4);
+            assertTrue(response4!= null);
+            assertTrue(compareArrays(request4, response4));  // Response 4 should be the same as Request 1
+            
+            // Test sending "Hello World"
+            // Note that the Hello World remains one item.
+            String[] request5 = new String[] {"Hello World"};
+            String[] response5 = proxy.echoStringArrayAlt(request5);
+            assertTrue(response5!= null);
+            assertTrue(compareArrays(request5, response5)); // Response 5 should be the same as Request 1
+        }catch(Exception e){ 
+            e.printStackTrace(); 
+            fail("Exception received" + e);
+        }
+    }
+    
+    private boolean compareLists(List in, List out) {
+        if (in.size() != out.size()) {
+            TestLogger.logger.debug("Size mismatch " + in.size() + "!=" + out.size());
+            return false;
+        }
+        for (int i=0; i<in.size(); i++) {
+            Object inItem = in.get(i);
+            Object outItem = out.get(i);
+            if (inItem != null && !inItem.equals(outItem) ||
+                (inItem == null && inItem != outItem)) {
+                TestLogger.logger.debug("Item " + i + " mismatch " + inItem + "!=" + outItem);
+                return false;
+            }
+                
+        }
+        return true;
+    }
+    
+    private boolean compareArrays(String[] in, String[] out) {
+        if (in.length != out.length) {
+            TestLogger.logger.debug("Size mismatch " + in.length + "!=" + out.length);
+            return false;
+        }
+        for (int i=0; i<in.length; i++) {
+            Object inItem = in[i];
+            Object outItem = out[i];
+            if (inItem != null && !inItem.equals(outItem) ||
+                (inItem == null && inItem != outItem)) {
+                TestLogger.logger.debug("Item " + i + " mismatch " + inItem + "!=" + outItem);
+                return false;
+            }
+                
+        }
+        return true;
+    }
+}
\ No newline at end of file

Added: webservices/axis2/trunk/java/modules/jaxws-integration/test/org/apache/axis2/jaxws/proxy/ProxyNonWrappedTests.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/jaxws-integration/test/org/apache/axis2/jaxws/proxy/ProxyNonWrappedTests.java?rev=633234&view=auto
==============================================================================
--- webservices/axis2/trunk/java/modules/jaxws-integration/test/org/apache/axis2/jaxws/proxy/ProxyNonWrappedTests.java (added)
+++ webservices/axis2/trunk/java/modules/jaxws-integration/test/org/apache/axis2/jaxws/proxy/ProxyNonWrappedTests.java Mon Mar  3 10:47:38 2008
@@ -0,0 +1,137 @@
+/*
+ * 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.jaxws.proxy;
+
+import java.io.File;
+import java.net.URL;
+import java.util.concurrent.Future;
+
+import javax.xml.namespace.QName;
+import javax.xml.ws.AsyncHandler;
+import javax.xml.ws.BindingProvider;
+import javax.xml.ws.Service;
+
+import junit.framework.TestCase;
+import org.apache.axis2.jaxws.proxy.doclitnonwrapped.sei.DocLitnonWrappedProxy;
+import org.apache.axis2.jaxws.proxy.doclitnonwrapped.sei.ProxyDocLitUnwrappedService;
+import org.apache.axis2.jaxws.TestLogger;
+import org.test.proxy.doclitnonwrapped.Invoke;
+import org.test.proxy.doclitnonwrapped.ObjectFactory;
+import org.test.proxy.doclitnonwrapped.ReturnType;
+
+/**
+ * This test cases will use proxy NON wrapped wsdl to invoke methods
+ * on a deployed Server Endpoint.
+ */
+public class ProxyNonWrappedTests extends TestCase {
+
+    QName serviceName = new QName("http://doclitnonwrapped.proxy.test.org", "ProxyDocLitUnwrappedService");
+    private String axisEndpoint = "http://localhost:6060/axis2/services/ProxyDocLitUnwrappedService.DocLitnonWrappedImplPort";
+    private QName portName = new QName("http://org.apache.axis2.proxy.doclitwrapped", "ProxyDocLitWrappedPort");
+    private String wsdlLocation = System.getProperty("basedir",".")+"/"+"test-resources/wsdl/ProxyDocLitnonWrapped.wsdl";
+    public ProxyNonWrappedTests() {
+        super();
+        // TODO Auto-generated constructor stub
+    }
+
+    /**
+     * @param arg0
+     */
+    public ProxyNonWrappedTests(String arg0) {
+        super(arg0);
+        // TODO Auto-generated constructor stub
+    }
+    
+    public void testInvoke(){
+        TestLogger.logger.debug("-----------------------------------");
+        TestLogger.logger.debug("test: " + getName());
+        TestLogger.logger.debug(">>Testing Sync Inovoke on Proxy DocLit non-wrapped");
+        ObjectFactory factory = new ObjectFactory();
+        Invoke invokeObj = factory.createInvoke();
+        invokeObj.setInvokeStr("test request for twoWay Operation");
+        Service service = Service.create(null, serviceName);
+        assertNotNull(service);
+        DocLitnonWrappedProxy proxy = service.getPort(portName, DocLitnonWrappedProxy.class);
+        assertNotNull(proxy);
+        BindingProvider p = (BindingProvider)proxy;
+        p.getRequestContext().put(BindingProvider.ENDPOINT_ADDRESS_PROPERTY,axisEndpoint);
+        ReturnType response = proxy.invoke(invokeObj);
+        assertNotNull(response);
+        TestLogger.logger.debug(">>Response =" + response.getReturnStr());
+
+        TestLogger.logger.debug("-------------------------------------");
+    }
+    
+    public void testNullInvoke(){
+        TestLogger.logger.debug("-----------------------------------");
+        TestLogger.logger.debug("test: " + getName());
+        TestLogger.logger.debug(">>Testing Sync Invoke on Proxy DocLit bare with a null parameter");
+        ObjectFactory factory = new ObjectFactory();
+        Invoke invokeObj = null;
+        Service service = Service.create(null, serviceName);
+        assertNotNull(service);
+        DocLitnonWrappedProxy proxy = service.getPort(portName, DocLitnonWrappedProxy.class);
+        assertNotNull(proxy);
+        BindingProvider p = (BindingProvider)proxy;
+        p.getRequestContext().put(BindingProvider.ENDPOINT_ADDRESS_PROPERTY,axisEndpoint);
+        ReturnType response = proxy.invoke(invokeObj);
+        assertNull(response);
+
+        TestLogger.logger.debug("-------------------------------------");
+    }
+    
+    public void testInvokeAsyncCallback(){
+        try{
+            TestLogger.logger.debug("---------------------------------------");
+            TestLogger.logger.debug("DocLitNonWrapped test case: " + getName());
+            //Create wsdl url
+            File wsdl= new File(wsdlLocation); 
+            URL wsdlUrl = wsdl.toURL(); 
+            ObjectFactory factory = new ObjectFactory();
+            //create input object to web service operation
+            Invoke invokeObj = factory.createInvoke();
+            invokeObj.setInvokeStr("test request for twoWay Async Operation");
+            //Create Service
+            ProxyDocLitUnwrappedService service = new ProxyDocLitUnwrappedService(wsdlUrl, serviceName);
+            //Create proxy
+            DocLitnonWrappedProxy proxy = service.getProxyDocLitnonWrappedPort();
+            TestLogger.logger.debug(">>Invoking Binding Provider property");
+            //Setup Endpoint url -- optional.
+            BindingProvider p = (BindingProvider)proxy;
+                p.getRequestContext().put(BindingProvider.ENDPOINT_ADDRESS_PROPERTY,axisEndpoint);
+            TestLogger.logger.debug(">> Invoking Proxy Asynchronous Callback");
+            AsyncHandler<ReturnType> handler = new AsyncCallback();
+            //Invoke operation Asynchronously.
+            Future<?> monitor = proxy.invokeAsync(invokeObj, handler);
+            while(!monitor.isDone()){
+                Thread.sleep(1000);
+            }
+            TestLogger.logger.debug("---------------------------------------");
+        }catch(Exception e){ 
+            e.printStackTrace(); 
+            fail("Exception received" + e);
+        }
+    }
+    
+    public void testInvokeAsyncPolling(){
+        
+    }
+
+}
+

Added: webservices/axis2/trunk/java/modules/jaxws-integration/test/org/apache/axis2/jaxws/proxy/ProxyTests.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/jaxws-integration/test/org/apache/axis2/jaxws/proxy/ProxyTests.java?rev=633234&view=auto
==============================================================================
--- webservices/axis2/trunk/java/modules/jaxws-integration/test/org/apache/axis2/jaxws/proxy/ProxyTests.java (added)
+++ webservices/axis2/trunk/java/modules/jaxws-integration/test/org/apache/axis2/jaxws/proxy/ProxyTests.java Mon Mar  3 10:47:38 2008
@@ -0,0 +1,280 @@
+/*
+ * 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.jaxws.proxy;
+
+import java.io.File;
+import java.net.URL;
+import java.util.concurrent.Future;
+
+import javax.xml.namespace.QName;
+import javax.xml.ws.AsyncHandler;
+import javax.xml.ws.BindingProvider;
+import javax.xml.ws.Response;
+import javax.xml.ws.Service;
+
+import junit.framework.TestCase;
+import org.apache.axis2.jaxws.proxy.doclitwrapped.sei.DocLitWrappedProxy;
+import org.apache.axis2.jaxws.proxy.doclitwrapped.sei.ProxyDocLitWrappedService;
+import org.apache.axis2.jaxws.TestLogger;
+import org.test.proxy.doclitwrapped.ReturnType;
+
+public class ProxyTests extends TestCase {
+    private QName serviceName = new QName(
+            "http://doclitwrapped.proxy.test.org", "ProxyDocLitWrappedService");
+    private String axisEndpoint = "http://localhost:6060/axis2/services/ProxyDocLitWrappedService.DocLitWrappedProxyImplPort";
+    private QName portName = new QName("http://doclitwrapped.proxy.test.org",
+            "ProxyDocLitWrappedPort");
+    private String wsdlLocation = System.getProperty("basedir",".")+"/"+"test/org/apache/axis2/jaxws/proxy/doclitwrapped/META-INF/ProxyDocLitWrapped.wsdl";
+    private boolean runningOnAxis = true;
+    
+    public void testMultipleServiceCalls(){
+        try{
+            if(!runningOnAxis){
+                return;
+            }
+            TestLogger.logger.debug("---------------------------------------");
+            TestLogger.logger.debug("test:" + getName());
+            String request = new String("some string request");
+            TestLogger.logger.debug("Service Call #1");
+            ProxyDocLitWrappedService service1 = new ProxyDocLitWrappedService();
+            DocLitWrappedProxy proxy1 = service1.getProxyDocLitWrappedPort();
+            BindingProvider p1 =    (BindingProvider)proxy1;
+            p1.getRequestContext().put(BindingProvider.ENDPOINT_ADDRESS_PROPERTY,axisEndpoint);
+            String response1 = proxy1.invoke(request);
+            TestLogger.logger.debug("Proxy Response =" + response1);
+            TestLogger.logger.debug("---------------------------------------");
+
+            TestLogger.logger.debug("Service Call #2");
+            ProxyDocLitWrappedService service2 = new ProxyDocLitWrappedService();
+            DocLitWrappedProxy proxy2 = service2.getProxyDocLitWrappedPort();
+            BindingProvider p2 =    (BindingProvider)proxy2;
+            p2.getRequestContext().put(BindingProvider.ENDPOINT_ADDRESS_PROPERTY,axisEndpoint);
+            String response2 = proxy2.invoke(request);
+            TestLogger.logger.debug("Proxy Response =" + response2);
+            TestLogger.logger.debug("---------------------------------------");
+            
+        }catch(Exception e){
+            //fail(getName() + " failed");
+            e.printStackTrace();
+        }
+    }
+    
+    public void testInvokeWithNullParam(){
+        try{ 
+            if(!runningOnAxis){
+                return;
+            }
+            TestLogger.logger.debug("---------------------------------------");
+            TestLogger.logger.debug("Test Name: " + getName());
+            File wsdl= new File(wsdlLocation); 
+            URL wsdlUrl = wsdl.toURL(); 
+            Service service = Service.create(null, serviceName); 
+            Object proxy =service.getPort(portName, DocLitWrappedProxy.class);
+            TestLogger.logger.debug(">>Invoking Binding Provider property");
+            BindingProvider p = (BindingProvider)proxy;
+            p.getRequestContext().put(BindingProvider.ENDPOINT_ADDRESS_PROPERTY,axisEndpoint);
+
+            DocLitWrappedProxy dwp = (DocLitWrappedProxy)proxy;
+            TestLogger.logger.debug(">> Invoking Proxy Synchronously");
+            String request = null;
+            String response = dwp.invoke(request);
+            TestLogger.logger.debug("Proxy Response =" + response);
+            TestLogger.logger.debug("---------------------------------------");
+        }catch(Exception e){ 
+            e.printStackTrace(); 
+            fail("Exception received" + e);
+        }
+    }
+    public void testInvoke(){
+        try{ 
+            if(!runningOnAxis){
+                return;
+            }
+            TestLogger.logger.debug("---------------------------------------");
+            
+            File wsdl= new File(wsdlLocation); 
+            URL wsdlUrl = wsdl.toURL(); 
+            Service service = Service.create(null, serviceName);
+            String request = new String("some string request"); 
+            Object proxy =service.getPort(portName, DocLitWrappedProxy.class);
+            TestLogger.logger.debug(">>Invoking Binding Provider property");
+            BindingProvider p = (BindingProvider)proxy;
+                p.getRequestContext().put(BindingProvider.ENDPOINT_ADDRESS_PROPERTY,axisEndpoint);
+                
+            DocLitWrappedProxy dwp = (DocLitWrappedProxy)proxy;
+            TestLogger.logger.debug(">> Invoking Proxy Synchronously");
+            String response = dwp.invoke(request);
+            TestLogger.logger.debug("Proxy Response =" + response);
+            TestLogger.logger.debug("---------------------------------------");
+        }catch(Exception e){ 
+            e.printStackTrace(); 
+            fail("Exception received" + e);
+        }
+    }
+
+    public void testInvokeWithWSDL(){
+        try{ 
+            if(!runningOnAxis){
+                return;
+            }
+            TestLogger.logger.debug("---------------------------------------");
+            File wsdl= new File(wsdlLocation); 
+            URL wsdlUrl = wsdl.toURL(); 
+            Service service = Service.create(wsdlUrl, serviceName);
+            String request = new String("some string request"); 
+            Object proxy =service.getPort(portName, DocLitWrappedProxy.class);
+            TestLogger.logger.debug(">>Invoking Binding Provider property");
+            BindingProvider p = (BindingProvider)proxy;
+            p.getRequestContext().put(BindingProvider.ENDPOINT_ADDRESS_PROPERTY,axisEndpoint);
+                
+            DocLitWrappedProxy dwp = (DocLitWrappedProxy)proxy;
+            TestLogger.logger.debug(">> Invoking Proxy Synchronously");
+            String response = dwp.invoke(request);
+            TestLogger.logger.debug("Proxy Response =" + response);
+            TestLogger.logger.debug("---------------------------------------");
+        }catch(Exception e){ 
+            e.printStackTrace(); 
+            fail("Exception received" + e);
+        }
+    }
+    
+    public void testInvokeAsyncCallback(){
+        try{ 
+            if(!runningOnAxis){
+                return;
+            }
+            TestLogger.logger.debug("---------------------------------------");
+            
+            File wsdl= new File(wsdlLocation); 
+            URL wsdlUrl = wsdl.toURL(); 
+            Service service = Service.create(null, serviceName);
+            String request = new String("some string request"); 
+            Object proxy =service.getPort(portName, DocLitWrappedProxy.class);
+            TestLogger.logger.debug(">>Invoking Binding Provider property");
+            BindingProvider p = (BindingProvider)proxy;
+                p.getRequestContext().put(BindingProvider.ENDPOINT_ADDRESS_PROPERTY,axisEndpoint);
+                
+            DocLitWrappedProxy dwp = (DocLitWrappedProxy)proxy;
+            TestLogger.logger.debug(">> Invoking Proxy Asynchronous Callback");
+            AsyncHandler handler = new AsyncCallback();
+            Future<?> response = dwp.invokeAsync(request, handler);
+            TestLogger.logger.debug("---------------------------------------");
+        }catch(Exception e){ 
+            e.printStackTrace(); 
+            fail("Exception received" + e);
+        }
+    }
+    
+    public void testInvokeAsyncPolling() {
+        try {
+            TestLogger.logger.debug("---------------------------------------");
+            
+            File wsdl= new File(wsdlLocation); 
+            URL wsdlUrl = wsdl.toURL(); 
+            Service service = Service.create(null, serviceName);
+            DocLitWrappedProxy proxy =service.getPort(portName, DocLitWrappedProxy.class);
+            
+            String request = new String("some string request");
+
+            TestLogger.logger.debug(">> Invoking Binding Provider property");
+            BindingProvider p = (BindingProvider) proxy;
+            p.getRequestContext().put(BindingProvider.ENDPOINT_ADDRESS_PROPERTY, axisEndpoint);
+
+            TestLogger.logger.debug(">> Invoking Proxy with async polling request");
+            Response<ReturnType> asyncResponse = proxy.invokeAsync(request);
+
+            while (!asyncResponse.isDone()) {
+                TestLogger.logger.debug(">> Async invocation still not complete");
+                Thread.sleep(1000);
+            }
+            
+            ReturnType response = asyncResponse.get();
+            assertNotNull(response);
+        }
+        catch(Exception e) { 
+            e.printStackTrace(); 
+            fail("Exception received" + e);
+        }
+    }
+    
+    public void testTwoWay(){
+        /*
+        try{ 
+            if(runningOnAxis){
+                return;
+            }
+            File wsdl= new File(wsdlLocation); 
+            URL wsdlUrl = wsdl.toURL(); 
+            Service service = Service.create(null, serviceName);
+            String request = new String("some string request"); 
+            
+            Object proxy =service.getPort(portName, DocLitWrappedProxy.class); 
+            BindingProvider p = (BindingProvider)proxy;
+            p.getRequestContext().put(BindingProvider.ENDPOINT_ADDRESS_PROPERTY,wasEndpoint);
+                
+            DocLitWrappedProxy dwp = (DocLitWrappedProxy)proxy;  
+            String response = dwp.twoWay(request);
+            System.out.println("Response =" + response);
+        }catch(Exception e){ 
+            e.printStackTrace(); 
+            fail("Exception received" + e);
+        }
+        */
+    }
+    
+    public void testOneWay(){
+        
+    }
+    
+    public void testHolder(){
+        
+    }
+    
+    public void testTwoWayAsyncCallback(){
+        /*
+        try{ 
+            if(runningOnAxis){
+                return;
+            }
+            File wsdl= new File(wsdlLocation); 
+            URL wsdlUrl = wsdl.toURL(); 
+            Service service = Service.create(null, serviceName);
+            
+            String request = new String("some string request"); 
+            
+            Object proxy =service.getPort(portName, DocLitWrappedProxy.class); 
+            BindingProvider p = (BindingProvider)proxy;
+                p.getRequestContext().put(BindingProvider.ENDPOINT_ADDRESS_PROPERTY,wasEndpoint);
+                
+            DocLitWrappedProxy dwp = (DocLitWrappedProxy)proxy;
+            AsyncHandler handler = new AsyncCallback();
+            Future<?> response = dwp.twoWayAsync(request, handler);
+            
+        }catch(Exception e){ 
+            e.printStackTrace(); 
+            fail("Exception received" + e);
+        }
+        */
+    }
+    
+    public void testAsyncPooling(){
+        
+    }
+}
+

Added: webservices/axis2/trunk/java/modules/jaxws-integration/test/org/apache/axis2/jaxws/proxy/RPCLitSWAProxyTests.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/jaxws-integration/test/org/apache/axis2/jaxws/proxy/RPCLitSWAProxyTests.java?rev=633234&view=auto
==============================================================================
--- webservices/axis2/trunk/java/modules/jaxws-integration/test/org/apache/axis2/jaxws/proxy/RPCLitSWAProxyTests.java (added)
+++ webservices/axis2/trunk/java/modules/jaxws-integration/test/org/apache/axis2/jaxws/proxy/RPCLitSWAProxyTests.java Mon Mar  3 10:47:38 2008
@@ -0,0 +1,159 @@
+/*
+ * 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.jaxws.proxy;
+
+import org.apache.axis2.jaxws.provider.DataSourceImpl;
+import org.apache.axis2.jaxws.proxy.rpclitswa.sei.RPCLitSWA;
+
+import javax.activation.DataHandler;
+import javax.activation.DataSource;
+import javax.imageio.ImageIO;
+import javax.imageio.stream.FileImageInputStream;
+import javax.imageio.stream.ImageInputStream;
+import javax.xml.namespace.QName;
+import javax.xml.ws.BindingProvider;
+import javax.xml.ws.Dispatch;
+import javax.xml.ws.Holder;
+import javax.xml.ws.Service;
+
+import java.awt.Image;
+import java.io.File;
+import java.net.MalformedURLException;
+import java.net.URL;
+
+import junit.framework.TestCase;
+
+public class RPCLitSWAProxyTests extends TestCase {
+
+    private QName serviceName = new QName(
+            "http://org/apache/axis2/jaxws/proxy/rpclitswa", "RPCLitSWAService");
+    private String axisEndpoint = "http://localhost:6060/axis2/services/RPCLitSWAService.RPCLitSWA";
+    private QName portName = new QName("http://org/apache/axis2/jaxws/proxy/rpclitswa",
+            "RPCLitSWA");
+    private String wsdlLocation = System.getProperty("basedir",".")+"/"+
+    "test/org/apache/axis2/jaxws/proxy/rpclitswa/META-INF/RPCLitSWA.wsdl";
+        
+    private DataSource imageDS;
+    
+    public void setUp() throws Exception {
+        String imageResourceDir =
+                System.getProperty("basedir", ".") + "/" + "test-resources" + File.separator
+                        + "image";
+
+        //Create a DataSource from an image 
+        File file = new File(imageResourceDir + File.separator + "test.jpg");
+        ImageInputStream fiis = new FileImageInputStream(file);
+        Image image = ImageIO.read(fiis);
+        imageDS = new DataSourceImpl("image/jpeg", "test.jpg", image);
+    }
+    
+    /**
+     * Utility method to get the proxy
+     * @return RPCLit proxy
+     * @throws MalformedURLException
+     */
+    public RPCLitSWA getProxy() throws MalformedURLException {
+        File wsdl= new File(wsdlLocation);
+        assertTrue("WSDL does not exist:" + wsdlLocation,wsdl.exists());
+        URL wsdlUrl = wsdl.toURL(); 
+        Service service = Service.create(wsdlUrl, serviceName);
+        Object proxy =service.getPort(portName, RPCLitSWA.class);
+        BindingProvider p = (BindingProvider)proxy; 
+        p.getRequestContext().put(BindingProvider.ENDPOINT_ADDRESS_PROPERTY,axisEndpoint);
+        
+        return (RPCLitSWA)proxy;
+    }
+    
+    /**
+     * Utility Method to get a Dispatch<String>
+     * @return
+     * @throws MalformedURLException
+     */
+    public Dispatch<String> getDispatch() throws MalformedURLException {
+        File wsdl= new File(wsdlLocation); 
+        URL wsdlUrl = wsdl.toURL(); 
+        Service service = Service.create(null, serviceName);
+        service.addPort(portName, null, axisEndpoint);
+        Dispatch<String> dispatch = service.createDispatch(portName, String.class, 
+                                                           Service.Mode.PAYLOAD);
+        return dispatch;
+    }
+    
+    public void testNOOP() {
+        
+    }
+    
+    /**
+     * Simple test that ensures that we can echo a string to an rpc/lit web service
+     * NOTE:
+     * To enable this test, remove the _.
+     * Once you do this, you can add the following code to OperationDescriptionImpl.
+     * buildAttachmentInformation()
+     * // TODO: Start HACK for RPCLitSWAProxyTest
+        addPartAttachmentDescription("dummyAttachmentIN",
+                                     new AttachmentDescriptionImpl(AttachmentType.SWA, 
+                                                                   new String[] {"text/plain"}));
+        addPartAttachmentDescription("dummyAttachmentINOUT",
+                                     new AttachmentDescriptionImpl(AttachmentType.SWA, 
+                                                                   new String[] {"image/jpeg"}));
+        addPartAttachmentDescription("dummyAttachmentOUT",
+                                     new AttachmentDescriptionImpl(AttachmentType.SWA, 
+                                                                   new String[] {"text/plain"}));
+        // TODO: End HACK for RPCListSWAProxyTest
+     */
+    public void testRPCLitSWAEcho() throws Exception {
+        
+            RPCLitSWA proxy = getProxy();
+            String request = "This is a not attachment data";
+            
+            String attachmentIN = "Data for plain text attachment";
+            DataHandler attachmentINOUT = getImageDH();
+            
+            Holder<DataHandler> attachmentINOUT_Holder = new Holder<DataHandler>();
+            attachmentINOUT_Holder.value = attachmentINOUT;
+            Holder<String> response_Holder = new Holder<String>();
+            Holder<String> attachmentOUT_Holder = new Holder<String>();
+           
+            proxy.echo(request, attachmentIN, attachmentINOUT_Holder, response_Holder, 
+                       attachmentOUT_Holder);
+            
+            assertTrue("Bad Response Holder", response_Holder != null);
+            assertTrue("Response value is null", response_Holder.value != null);
+            assertTrue("Response is not the same as request. Receive="+response_Holder.value, 
+                       request.equals(response_Holder.value));
+            
+            assertTrue("The output attachment holder is null", attachmentOUT_Holder != null);
+            assertTrue("The output attachment is null", attachmentOUT_Holder.value != null);
+            assertTrue("The output attachment is not the same as the input.  Received=" + 
+                       attachmentOUT_Holder.value, 
+                    attachmentIN.equals(attachmentOUT_Holder.value));
+            
+           
+            assertTrue("The inout attachment holder is null", attachmentINOUT_Holder != null);
+            assertTrue("The inout attachment is null", attachmentINOUT_Holder.value != null);
+            // Ensure that this is not the same object
+            assertTrue(attachmentINOUT_Holder.value != attachmentINOUT);  
+        
+    }
+    
+    private DataHandler getImageDH() {
+        return new DataHandler(imageDS);
+    }
+    
+}

Added: webservices/axis2/trunk/java/modules/jaxws-integration/test/org/apache/axis2/jaxws/proxy/RPCProxyTests.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/jaxws-integration/test/org/apache/axis2/jaxws/proxy/RPCProxyTests.java?rev=633234&view=auto
==============================================================================
--- webservices/axis2/trunk/java/modules/jaxws-integration/test/org/apache/axis2/jaxws/proxy/RPCProxyTests.java (added)
+++ webservices/axis2/trunk/java/modules/jaxws-integration/test/org/apache/axis2/jaxws/proxy/RPCProxyTests.java Mon Mar  3 10:47:38 2008
@@ -0,0 +1,421 @@
+/*
+ * 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.jaxws.proxy;
+
+import java.io.File;
+import java.math.BigInteger;
+import java.net.MalformedURLException;
+import java.net.URL;
+
+import javax.xml.bind.JAXBContext;
+import javax.xml.bind.JAXBElement;
+import javax.xml.bind.Marshaller;
+import javax.xml.datatype.XMLGregorianCalendar;
+import javax.xml.namespace.QName;
+import javax.xml.ws.BindingProvider;
+import javax.xml.ws.Dispatch;
+import javax.xml.ws.Holder;
+import javax.xml.ws.Service;
+import javax.xml.ws.WebServiceException;
+
+import junit.framework.TestCase;
+import org.apache.axis2.jaxws.proxy.rpclit.RPCLitImpl;
+import org.apache.axis2.jaxws.proxy.rpclit.sei.RPCFault;
+import org.apache.axis2.jaxws.proxy.rpclit.sei.RPCLit;
+import org.apache.axis2.jaxws.TestLogger;
+import org.test.proxy.rpclit.ComplexAll;
+import org.test.proxy.rpclit.Enum;
+
+public class RPCProxyTests extends TestCase {
+
+    private QName serviceName = new QName(
+            "http://org.apache.axis2.jaxws.proxy.rpclit", "RPCLitService");
+    private String axisEndpoint = "http://localhost:6060/axis2/services/RPCLitService.RPCLitImplPort";
+    private QName portName = new QName("http://org.apache.axis2.jaxws.proxy.rpclit",
+            "RPCLit");
+    private String wsdlLocation = System.getProperty("basedir",".")+"/"+"test/org/apache/axis2/jaxws/proxy/rpclit/META-INF/RPCLit.wsdl";
+    
+    /**
+     * Utility method to get the proxy
+     * @return RPCLit proxy
+     * @throws MalformedURLException
+     */
+    public RPCLit getProxy() throws MalformedURLException {
+        File wsdl= new File(wsdlLocation); 
+        URL wsdlUrl = wsdl.toURL(); 
+        Service service = Service.create(null, serviceName);
+        Object proxy =service.getPort(portName, RPCLit.class);
+        BindingProvider p = (BindingProvider)proxy; 
+        p.getRequestContext().put(BindingProvider.ENDPOINT_ADDRESS_PROPERTY,axisEndpoint);
+        
+        return (RPCLit)proxy;
+    }
+    
+    /**
+     * Utility Method to get a Dispatch<String>
+     * @return
+     * @throws MalformedURLException
+     */
+    public Dispatch<String> getDispatch() throws MalformedURLException {
+        File wsdl= new File(wsdlLocation); 
+        URL wsdlUrl = wsdl.toURL(); 
+        Service service = Service.create(null, serviceName);
+        service.addPort(portName, null, axisEndpoint);
+        Dispatch<String> dispatch = service.createDispatch(portName, String.class, Service.Mode.PAYLOAD);
+        return dispatch;
+    }
+    
+    /**
+     * Simple test that ensures that we can echo a string to an rpc/lit web service
+     */
+    public void testSimple() throws Exception {
+        try{ 
+            RPCLit proxy = getProxy();
+            String request = "This is a test...";
+           
+            String response = proxy.testSimple(request);
+            assertTrue(response != null);
+            assertTrue(response.equals(request));
+        }catch(Exception e){ 
+            e.printStackTrace(); 
+            fail("Exception received" + e);
+        }
+    }
+    
+    /**
+     * Simple test that ensures that we can echo a string to an rpc/lit web service
+     */
+    public void testSimpleInOut() throws Exception {
+        try{ 
+            RPCLit proxy = getProxy();
+            String request = "This is a test...";
+            Holder<String> requestParam = new Holder<String>();
+            requestParam.value = request;
+           
+            String response = proxy.testSimpleInOut(requestParam);
+            assertTrue(response != null);
+            assertTrue(response.equals(request));
+            assertTrue(requestParam.value.equals(request));
+        }catch(Exception e){ 
+            e.printStackTrace(); 
+            fail("Exception received" + e);
+        }
+    }
+    
+    /**
+     * Simple test that ensures that we can echo a string to an rpc/lit web service
+     */
+    public void testSimple2() throws Exception {
+        try{ 
+            RPCLit proxy = getProxy();
+            String request1 = "hello";
+            String request2 = "world";
+           
+            String response = proxy.testSimple2(request1, request2);
+            assertTrue(response != null);
+            assertTrue(response.equals("helloworld"));
+        }catch(Exception e){ 
+            e.printStackTrace(); 
+            fail("Exception received" + e);
+        }
+    }
+    
+    /**
+     * Simple test that ensures that we can echo a string to an rpc/lit web service.
+     * This test passes the information in headers
+     */
+    public void testHeader() throws Exception {
+        RPCLit proxy = getProxy();
+        String request1 = "hello";
+        String request2 = "world";
+        
+        String response = proxy.testHeader(request1, request2);
+        assertTrue(response != null);
+        assertTrue(response.equals("helloworld"));
+        
+    }
+    
+    /**
+     * Simple test that ensures that a service fault is thrown correctly
+     */
+    public void testFault() throws Exception {
+        try{ 
+            RPCLit proxy = getProxy();
+     
+            proxy.testFault();
+            fail("Expected RPCFault");
+        } catch(RPCFault rpcFault){ 
+            assertTrue(rpcFault.getMessage().equals("Throw RPCFault"));
+            assertTrue(rpcFault.getFaultInfo() == 123);
+        } catch(Exception e){ 
+            e.printStackTrace(); 
+            fail("Exception received" + e);
+        }
+    }
+    
+    /**
+     * Simple test that ensures that we can echo a string to an rpc/lit web service
+     */
+    public void testForNull() throws Exception {
+        try{ 
+            RPCLit proxy = getProxy();
+            String request = null;
+           
+            String response = proxy.testSimple(request);
+            fail("RPC/LIT should throw webserviceException when operation is invoked with null input parameter");
+        }catch(Exception e){ 
+            assertTrue(e instanceof WebServiceException);
+            TestLogger.logger.debug(e.getMessage());
+        }
+    }
+    
+    /**
+     * Simple test that ensures that we can echo a string to an rpc/lit web service
+     */
+    public void testForNullReturn() throws Exception {
+        try{ 
+            RPCLit proxy = getProxy();
+           
+            String response = proxy.testSimple("returnNull");
+            fail("RPC/LIT should throw webserviceException when operation is invoked with null out parameter");
+        }catch(Exception e){ 
+            assertTrue(e instanceof WebServiceException);
+            TestLogger.logger.debug(e.getMessage());
+        }
+    }
+    
+    
+    
+    public void testSimple_Dispatch() throws Exception {
+        // Send a payload that simulates
+        // the rpc message
+        String request = "<tns:testSimple xmlns:tns='http://org/apache/axis2/jaxws/proxy/rpclit'>" +
+        "<simpleIn xsi:type='xsd:string' xmlns:xsd='http://www.w3.org/2001/XMLSchema' xmlns:xsi='http://www.w3.org/2001/XMLSchema-instance'>" +
+        "PAYLOAD WITH XSI:TYPE" +
+        "</simpleIn></tns:testSimple>";
+        Dispatch<String> dispatch = getDispatch();
+        String response = dispatch.invoke(request);
+
+        assertNotNull("dispatch invoke returned null", response);
+        TestLogger.logger.debug(response);
+        
+        // Check to make sure the content is correct
+        assertTrue(!response.contains("soap"));
+        assertTrue(!response.contains("Envelope"));
+        assertTrue(!response.contains("Body"));
+        assertTrue(!response.contains("Fault"));
+        assertTrue(response.contains("simpleOut"));
+        assertTrue(!response.contains(":simpleOut"));  // Make sure simple out is not namespace qualified
+        assertTrue(response.contains(":testSimpleResponse"));  // Make sure response is namespace qualified  
+        assertTrue(response.contains("PAYLOAD WITH XSI:TYPE"));
+    }
+    
+    public void testSimple2_DispatchWithoutXSIType() throws Exception {
+        // Send a payload that simulates
+        // the rpc message
+        String request = "<tns:testSimple2 xmlns:tns='http://org/apache/axis2/jaxws/proxy/rpclit'>" +
+        "<simple2In1>" +
+        "HELLO" +
+        "</simple2In1>" +
+        "<simple2In2>" +
+        "WORLD" +
+        "</simple2In2></tns:testSimple2>";
+        Dispatch<String> dispatch = getDispatch();
+        String response = dispatch.invoke(request);
+        
+
+        assertNotNull("dispatch invoke returned null", response);
+        TestLogger.logger.debug(response);
+        
+        // Check to make sure the content is correct
+        assertTrue(!response.contains("soap"));
+        assertTrue(!response.contains("Envelope"));
+        assertTrue(!response.contains("Body"));
+        assertTrue(!response.contains("Fault"));
+        assertTrue(response.contains("simple2Out"));
+        assertTrue(!response.contains(":simple2Out"));// Make sure simpleOut is not namespace qualified
+        assertTrue(response.contains(":testSimple2Response")); 
+        assertTrue(response.contains("HELLOWORLD"));
+    }
+    
+    public void testSimple_DispatchWithoutXSIType() throws Exception {
+        // Send a payload that simulates
+        // the rpc message
+        String request = "<tns:testSimple xmlns:tns='http://org/apache/axis2/jaxws/proxy/rpclit'>" +
+        "<simpleIn>" +
+        "PAYLOAD WITHOUT XSI:TYPE" +
+        "</simpleIn></tns:testSimple>";
+        Dispatch<String> dispatch = getDispatch();
+        String response = dispatch.invoke(request);
+        
+
+        assertNotNull("dispatch invoke returned null", response);
+        TestLogger.logger.debug(response);
+        
+        // Check to make sure the content is correct
+        assertTrue(!response.contains("soap"));
+        assertTrue(!response.contains("Envelope"));
+        assertTrue(!response.contains("Body"));
+        assertTrue(!response.contains("Fault"));
+        assertTrue(response.contains("simpleOut"));
+        assertTrue(!response.contains(":simpleOut"));  // Make sure simpleOut is not namespace qualified
+        assertTrue(response.contains(":testSimpleResponse")); 
+        assertTrue(response.contains("PAYLOAD WITHOUT XSI:TYPE"));
+    }
+    
+    /**
+     * Simple test that ensures that we can echo a string to an rpc/lit web service.
+     */
+    public void testStringList() throws Exception {
+        try{ 
+            RPCLit proxy = getProxy();
+            String[] request = new String[] {"Hello" , "World"};
+           
+            String[] response = proxy.testStringList2(request);
+            assertTrue(response != null);
+            assertTrue(response.length==2);
+            assertTrue(response[0].equals("Hello"));
+            assertTrue(response[1].equals("World"));
+        }catch(Exception e){ 
+            e.printStackTrace(); 
+            fail("Exception received" + e);
+        }
+    }
+    
+    public void testStringList_Dispatch() throws Exception {
+        // Send a payload that simulates
+        // the rpc message
+        String request = "<tns:testStringList2 xmlns:tns='http://org/apache/axis2/jaxws/proxy/rpclit'>" +
+        //"<tns:arg_2_0 xmlns:tns='http://org/apache/axis2/jaxws/proxy/rpclit' xmlns:xsi='http://www.w3.org/2001/XMLSchema-instance' xsi:type='tns:StringList' >" +
+        "<tns:arg_2_0>" +
+        "Hello World" +
+        "</tns:arg_2_0></tns:testStringList2>";
+        Dispatch<String> dispatch = getDispatch();
+        String response = dispatch.invoke(request);
+
+        assertNotNull("dispatch invoke returned null", response);
+        TestLogger.logger.debug(response);
+        
+        // Check to make sure the content is correct
+        assertTrue(!response.contains("soap"));
+        assertTrue(!response.contains("Envelope"));
+        assertTrue(!response.contains("Body"));
+        assertTrue(!response.contains("Fault"));
+        assertTrue(response.contains("testStringList2Return"));
+        assertTrue(response.contains("testStringList2Response"));
+        assertTrue(response.contains("Hello World"));
+    }
+    /**
+     * Currently not enabled due to problems with 
+     * marshaling an xsd:list of QName.
+     * 
+     * Users should use document/literal processing if they 
+     * need such complicated scenarios.
+     */
+    public void _testLists() {
+        try{ 
+            RPCLit proxy = getProxy();
+            QName[] request = new QName[] {RPCLitImpl.qname1, RPCLitImpl.qname2};
+           
+            QName[] qNames = proxy.testLists(request,
+                    new XMLGregorianCalendar[0],
+                    new String[0],
+                    new BigInteger[0],
+                    new Long[0],
+                    new Enum[0],
+                    new String[0],
+                    new ComplexAll());
+            assertTrue(qNames.length==2);
+            assertTrue(qNames[0].equals(RPCLitImpl.qname1));
+            assertTrue(qNames[1].equals(RPCLitImpl.qname2));
+        }catch(Exception e){ 
+            e.printStackTrace(); 
+            fail("Exception received" + e);
+        }
+    }
+    
+    /**
+     * Currently not enabled due to problems marshalling/unmarshalling
+     * an xsd:list of XMLGregorianCalendar.
+     * 
+     * Users should use document/literal processing if they 
+     * need such complicated scenarios.
+     */
+    public void _testCalendars() {
+        try{ 
+            RPCLit proxy = getProxy();
+            XMLGregorianCalendar[] request = new XMLGregorianCalendar[] {RPCLitImpl.bday, RPCLitImpl.holiday};
+           
+            XMLGregorianCalendar[] cals  = proxy.testCalendarList1(request);
+            assertTrue(cals.length == 2);
+            assertTrue(cals[0].compare(RPCLitImpl.bday) == 0);
+            assertTrue(cals[1].compare(RPCLitImpl.holiday) == 0);
+        }catch(Exception e){ 
+            e.printStackTrace(); 
+            fail("Exception received" + e);
+        }
+    }
+    
+    public void testBigIntegers() {
+        try{ 
+            RPCLit proxy = getProxy();
+            BigInteger[] request = new BigInteger[] {RPCLitImpl.bigInt1, RPCLitImpl.bigInt2};
+           
+            BigInteger[] ints  = proxy.testBigIntegerList3(request);
+            assertTrue(ints.length==2);
+            assertTrue(ints[0].compareTo(RPCLitImpl.bigInt1) == 0);
+            assertTrue(ints[1].compareTo(RPCLitImpl.bigInt2) == 0);
+        }catch(Exception e){ 
+            e.printStackTrace(); 
+            fail("Exception received" + e);
+        }
+    }
+    
+    public void testLongs() {
+        try{ 
+            RPCLit proxy = getProxy();
+            Long[] request = new Long[] {new Long(0), new Long(1), new Long(2)};
+           
+            Long[] longs  = proxy.testLongList4(request);
+            assertTrue(longs.length==3);
+            assertTrue(longs[0] == 0);
+            assertTrue(longs[1] == 1);
+            assertTrue(longs[2] == 2);
+        }catch(Exception e){ 
+            e.printStackTrace(); 
+            fail("Exception received" + e);
+        }
+    }
+    
+    public void testEnums() {
+        try{ 
+            RPCLit proxy = getProxy();
+            Enum[] request = new Enum[] {Enum.ONE, Enum.TWO, Enum.THREE};
+           
+            Enum[] enums  = proxy.testEnumList5(request);
+            assertTrue(enums.length==3);
+            assertTrue(enums[0] == Enum.ONE);
+            assertTrue(enums[1] == Enum.TWO);
+            assertTrue(enums[2] == Enum.THREE);
+        }catch(Exception e){ 
+            e.printStackTrace(); 
+            fail("Exception received" + e);
+        }
+    }
+}

Added: webservices/axis2/trunk/java/modules/jaxws-integration/test/org/apache/axis2/jaxws/proxy/SOAP12ProxyTests.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/jaxws-integration/test/org/apache/axis2/jaxws/proxy/SOAP12ProxyTests.java?rev=633234&view=auto
==============================================================================
--- webservices/axis2/trunk/java/modules/jaxws-integration/test/org/apache/axis2/jaxws/proxy/SOAP12ProxyTests.java (added)
+++ webservices/axis2/trunk/java/modules/jaxws-integration/test/org/apache/axis2/jaxws/proxy/SOAP12ProxyTests.java Mon Mar  3 10:47:38 2008
@@ -0,0 +1,104 @@
+/*
+ * 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.jaxws.proxy;
+
+import javax.xml.namespace.QName;
+import javax.xml.ws.BindingProvider;
+import javax.xml.ws.WebServiceException;
+
+import junit.framework.TestCase;
+import org.apache.axis2.jaxws.proxy.soap12.Echo;
+import org.apache.axis2.jaxws.proxy.soap12.SOAP12EchoService;
+import org.apache.axis2.jaxws.TestLogger;
+
+/**
+ * A suite of tests to test dynamic proxy clients sending SOAP 1.2
+ * requests.  The endpoint can accept different keys to determine
+ * what it should send back.
+ */
+public class SOAP12ProxyTests extends TestCase {
+
+    private static final String SEND_SOAP11_RESPONSE = "RESPONSE-SOAP11";
+    private static final String SEND_SOAP12_RESPONSE = "RESPONSE-SOAP12";
+    String axisEndpoint = "http://localhost:6060/axis2/services/SOAP12EchoService.EchoPort";
+	
+
+    public SOAP12ProxyTests(String name) {
+        super(name);
+    }
+    
+    /**
+     * Send a SOAP 1.2 request and expect a SOAP 1.2 response.
+     */
+    public void testSOAP12RequestSOAP12Response() throws Exception {
+        TestLogger.logger.debug("---------------------------------------");
+        TestLogger.logger.debug("test: " + getName());
+        
+        // create the proxy instance.  the WSDL used by this proxy
+        // should have a proper SOAP 1.2 binding configured
+        SOAP12EchoService service = new SOAP12EchoService();
+        Echo proxy = service.getPort(new QName("http://jaxws.axis2.apache.org/proxy/soap12", "EchoPort"), Echo.class);
+        BindingProvider p = (BindingProvider) proxy;
+        p.getRequestContext().put(BindingProvider.ENDPOINT_ADDRESS_PROPERTY, axisEndpoint);
+
+        // invoke the remote operation.  send a key that tells the 
+        // service send back a SOAP 1.2 response.
+        String response = proxy.echo(SEND_SOAP12_RESPONSE);
+        TestLogger.logger.debug("response returned [" + response + "]");
+        
+        // validate the results
+        assertNotNull(response);
+        assertTrue(!response.equals("FAIL"));
+    }
+    
+    /**
+     * Send a SOAP 1.2 request, but have the server send back a SOAP 1.1
+     * response.  This should result in an exception.
+     */
+    // TODO fix and re-enable
+    public void _testSOAP12RequestSOAP11Response() {
+        TestLogger.logger.debug("---------------------------------------");
+        TestLogger.logger.debug("test: " + getName());
+        
+        // create the proxy instance.  the WSDL used by this proxy
+        // should have a proper SOAP 1.2 binding configured
+        SOAP12EchoService service = new SOAP12EchoService();
+        Echo proxy = service.getPort(new QName("http://jaxws.axis2.apache.org/proxy/soap12", "EchoPort"), Echo.class);
+        
+        // invoke the remote operation.  send a key that tells the 
+        // service send back a SOAP 1.1 response.  this should result
+        // in an error.
+        try {
+            String response = proxy.echo(SEND_SOAP11_RESPONSE);
+            TestLogger.logger.debug("response returned [" + response + "]");
+            
+            // if we've gotten this far, then something went wrong.
+            fail();
+        }
+        catch (WebServiceException wse) {
+            TestLogger.logger.debug("an exception was thrown, as expected");
+            TestLogger.logger.debug(wse.getMessage());
+        }
+    } 
+    
+    public void test() {
+        // NOOP
+    }
+
+}

Added: webservices/axis2/trunk/java/modules/jaxws-integration/test/org/apache/axis2/jaxws/proxy/doclitnonwrapped/DocLitnonWrappedImpl.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/jaxws-integration/test/org/apache/axis2/jaxws/proxy/doclitnonwrapped/DocLitnonWrappedImpl.java?rev=633234&view=auto
==============================================================================
--- webservices/axis2/trunk/java/modules/jaxws-integration/test/org/apache/axis2/jaxws/proxy/doclitnonwrapped/DocLitnonWrappedImpl.java (added)
+++ webservices/axis2/trunk/java/modules/jaxws-integration/test/org/apache/axis2/jaxws/proxy/doclitnonwrapped/DocLitnonWrappedImpl.java Mon Mar  3 10:47:38 2008
@@ -0,0 +1,50 @@
+/*
+ * 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.jaxws.proxy.doclitnonwrapped;
+
+import javax.xml.ws.BindingType;
+import javax.xml.ws.Provider;
+import javax.xml.ws.WebServiceProvider;
+import javax.xml.ws.http.HTTPBinding;
+
+import org.apache.axis2.jaxws.TestLogger;
+
+
+@WebServiceProvider(serviceName="ProxyDocLitUnwrappedService")
+@BindingType(HTTPBinding.HTTP_BINDING)
+public class DocLitnonWrappedImpl implements Provider<String> {
+
+	
+	public DocLitnonWrappedImpl() {
+		super();
+		// TODO Auto-generated constructor stub
+	}
+
+    /* (non-Javadoc)
+     * @see javax.xml.ws.Provider#invoke(T)
+     */
+    public String invoke(String invoke_str) {
+        TestLogger.logger.debug("End point called with String value =" + invoke_str);
+        if (invoke_str.contains("nil")) {
+            return new String("<ns2:ReturnType xsi:nil='true' xmlns:xsi='http://www.w3.org/2001/XMLSchema-instance' xmlns:ns2=\"http://doclitnonwrapped.proxy.test.org\"/>");
+        } else {
+            return new String("<ns2:ReturnType xmlns:ns2=\"http://doclitnonwrapped.proxy.test.org\"><return_str>some response</return_str></ns2:ReturnType>");
+        }
+    }
+}

Added: webservices/axis2/trunk/java/modules/jaxws-integration/test/org/apache/axis2/jaxws/proxy/doclitnonwrapped/sei/DocLitnonWrappedProxy.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/jaxws-integration/test/org/apache/axis2/jaxws/proxy/doclitnonwrapped/sei/DocLitnonWrappedProxy.java?rev=633234&view=auto
==============================================================================
--- webservices/axis2/trunk/java/modules/jaxws-integration/test/org/apache/axis2/jaxws/proxy/doclitnonwrapped/sei/DocLitnonWrappedProxy.java (added)
+++ webservices/axis2/trunk/java/modules/jaxws-integration/test/org/apache/axis2/jaxws/proxy/doclitnonwrapped/sei/DocLitnonWrappedProxy.java Mon Mar  3 10:47:38 2008
@@ -0,0 +1,84 @@
+
+/*
+ * 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.jaxws.proxy.doclitnonwrapped.sei;
+
+import java.util.concurrent.Future;
+
+import javax.jws.WebMethod;
+import javax.jws.WebParam;
+import javax.jws.WebResult;
+import javax.jws.WebService;
+import javax.jws.soap.SOAPBinding;
+import javax.jws.soap.SOAPBinding.ParameterStyle;
+import javax.xml.ws.AsyncHandler;
+import javax.xml.ws.Response;
+
+import org.test.proxy.doclitnonwrapped.Invoke;
+import org.test.proxy.doclitnonwrapped.ReturnType;
+
+
+/**
+ * This class was generated by the JAXWS SI.
+ * JAX-WS RI 2.0_01-b15-fcs
+ * Generated source version: 2.0
+ * 
+ */
+@WebService(name = "DocLitnonWrappedProxy", targetNamespace = "http://doclitnonwrapped.proxy.test.org")
+@SOAPBinding(parameterStyle = ParameterStyle.BARE)
+public interface DocLitnonWrappedProxy {
+	/**
+     * 
+     * @param allByMyself
+     * @return
+     *     returns javax.xml.ws.Response<org.test.proxy.doclitnonwrapped.ReturnType>
+     */
+    @WebMethod(operationName = "invoke", action = "http://doclitnonwrapped.proxy.test.org/invokeReturn")
+    public Response<ReturnType> invokeAsync(
+        @WebParam(name = "invoke", targetNamespace = "http://doclitnonwrapped.proxy.test.org", partName = "allByMyself")
+        Invoke allByMyself);
+
+    /**
+     * 
+     * @param allByMyself
+     * @param asyncHandler
+     * @return
+     *     returns java.util.concurrent.Future<? extends java.lang.Object>
+     */
+    @WebMethod(operationName = "invoke", action = "http://doclitnonwrapped.proxy.test.org/invokeReturn")
+    public Future<?> invokeAsync(
+        @WebParam(name = "invoke", targetNamespace = "http://doclitnonwrapped.proxy.test.org", partName = "allByMyself")
+        Invoke allByMyself,
+        @WebParam(name = "invokeResponse", targetNamespace = "", partName = "asyncHandler")
+        AsyncHandler<ReturnType> asyncHandler);
+
+
+    /**
+     * 
+     * @param allByMyself
+     * @return
+     *     returns org.test.proxy.doclitnonwrapped.ReturnType
+     */
+    @WebMethod(action = "http://doclitnonwrapped.proxy.test.org/invokeReturn")
+    @WebResult(name = "ReturnType", targetNamespace = "http://doclitnonwrapped.proxy.test.org", partName = "allByMyself")
+    public ReturnType invoke(
+        @WebParam(name = "invoke", targetNamespace = "http://doclitnonwrapped.proxy.test.org", partName = "allByMyself")
+        Invoke allByMyself);
+
+}

Added: webservices/axis2/trunk/java/modules/jaxws-integration/test/org/apache/axis2/jaxws/proxy/doclitnonwrapped/sei/ProxyDocLitUnwrappedService.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/jaxws-integration/test/org/apache/axis2/jaxws/proxy/doclitnonwrapped/sei/ProxyDocLitUnwrappedService.java?rev=633234&view=auto
==============================================================================
--- webservices/axis2/trunk/java/modules/jaxws-integration/test/org/apache/axis2/jaxws/proxy/doclitnonwrapped/sei/ProxyDocLitUnwrappedService.java (added)
+++ webservices/axis2/trunk/java/modules/jaxws-integration/test/org/apache/axis2/jaxws/proxy/doclitnonwrapped/sei/ProxyDocLitUnwrappedService.java Mon Mar  3 10:47:38 2008
@@ -0,0 +1,71 @@
+
+/*
+ * 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.jaxws.proxy.doclitnonwrapped.sei;
+
+import java.net.MalformedURLException;
+import java.net.URL;
+
+import javax.xml.namespace.QName;
+import javax.xml.ws.Service;
+import javax.xml.ws.WebEndpoint;
+import javax.xml.ws.WebServiceClient;
+
+/**
+ * This class was generated by the JAXWS SI.
+ * JAX-WS RI 2.0_01-b15-fcs
+ * Generated source version: 2.0
+ * 
+ */
+@WebServiceClient(name = "ProxyDocLitUnwrappedService", targetNamespace = "http://doclitnonwrapped.proxy.test.org", wsdlLocation = "proxy_doclit_unwr.wsdl")
+public class ProxyDocLitUnwrappedService
+    extends Service
+{
+
+    private final static URL PROXYDOCLITUNWRAPPEDSERVICE_WSDL_LOCATION;
+
+    static {
+        URL url = null;
+        try {
+            url = new URL("file:/C:/temp/proxy_doclit_unwr.wsdl");
+        } catch (MalformedURLException e) {
+            e.printStackTrace();
+        }
+        PROXYDOCLITUNWRAPPEDSERVICE_WSDL_LOCATION = url;
+    }
+
+    public ProxyDocLitUnwrappedService(URL wsdlLocation, QName serviceName) {
+        super(wsdlLocation, serviceName);
+    }
+
+    public ProxyDocLitUnwrappedService() {
+        super(PROXYDOCLITUNWRAPPEDSERVICE_WSDL_LOCATION, new QName("http://doclitnonwrapped.proxy.test.org", "ProxyDocLitUnwrappedService"));
+    }
+
+    /**
+     * 
+     * @return
+     *     returns DocLitnonWrappedProxy
+     */
+    @WebEndpoint(name = "ProxyDocLitnonWrappedPort")
+    public DocLitnonWrappedProxy getProxyDocLitnonWrappedPort() {
+        return (DocLitnonWrappedProxy)super.getPort(new QName("http://doclitnonwrapped.proxy.test.org", "ProxyDocLitnonWrappedPort"), DocLitnonWrappedProxy.class);
+    }
+
+}

Added: webservices/axis2/trunk/java/modules/jaxws-integration/test/org/apache/axis2/jaxws/proxy/doclitwrapped/DocLitWrappedProxyImpl.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/jaxws-integration/test/org/apache/axis2/jaxws/proxy/doclitwrapped/DocLitWrappedProxyImpl.java?rev=633234&view=auto
==============================================================================
--- webservices/axis2/trunk/java/modules/jaxws-integration/test/org/apache/axis2/jaxws/proxy/doclitwrapped/DocLitWrappedProxyImpl.java (added)
+++ webservices/axis2/trunk/java/modules/jaxws-integration/test/org/apache/axis2/jaxws/proxy/doclitwrapped/DocLitWrappedProxyImpl.java Mon Mar  3 10:47:38 2008
@@ -0,0 +1,37 @@
+/*
+ * 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.jaxws.proxy.doclitwrapped;
+
+import javax.xml.ws.BindingType;
+import javax.xml.ws.Provider;
+import javax.xml.ws.WebServiceProvider;
+import javax.xml.ws.http.HTTPBinding;
+
+import org.apache.axis2.jaxws.TestLogger;
+
+@WebServiceProvider(serviceName="ProxyDocLitWrappedService")
+@BindingType(HTTPBinding.HTTP_BINDING)
+public class DocLitWrappedProxyImpl implements Provider<String> {
+
+	public String invoke(String invoke_str) {
+		// TODO Auto-generated method stub
+        TestLogger.logger.debug("End point called with String value =" + invoke_str);
+		return new String("<ns2:ReturnType xmlns:ns2=\"http://doclitwrapped.proxy.test.org\"><return_str>some response</return_str></ns2:ReturnType>");
+	}
+}



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