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 de...@apache.org on 2007/02/08 07:41:17 UTC

svn commit: r504805 - in /webservices/axis2/trunk/java/modules: adb/src/org/apache/axis2/databinding/utils/ adb/src/org/apache/axis2/rpc/client/ adb/src/org/apache/axis2/rpc/receivers/ kernel/src/org/apache/axis2/deployment/ kernel/src/org/apache/axis2...

Author: deepal
Date: Wed Feb  7 22:41:16 2007
New Revision: 504805

URL: http://svn.apache.org/viewvc?view=rev&rev=504805
Log:
fixing AXIS2-1748
 - To have this feature you need to add one more file into META-INF directory called "wsdl.list" , and that file need to include all the wsdl files that you need to use (for example if you are trying to deploy a service group with multiple wsdl then name them in that file)
 - Added two resolvers to support the scenario (this will work for URLBasedAxisConfigurator as well)
AXIS2-1719
  - Test and confirm that is working

Added:
    webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/deployment/resolver/WarBasedWSDLLocator.java
    webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/deployment/resolver/WarFileBasedURIResolver.java
Modified:
    webservices/axis2/trunk/java/modules/adb/src/org/apache/axis2/databinding/utils/BeanUtil.java
    webservices/axis2/trunk/java/modules/adb/src/org/apache/axis2/rpc/client/RPCServiceClient.java
    webservices/axis2/trunk/java/modules/adb/src/org/apache/axis2/rpc/receivers/RPCUtil.java
    webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/deployment/DeploymentEngine.java
    webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/deployment/repository/util/ArchiveReader.java
    webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/description/WSDL11ToAxisServiceBuilder.java
    webservices/axis2/trunk/java/modules/samples/servicelifecycle/src/sample/servicelifecycle/LibraryLifeCycle.java
    webservices/axis2/trunk/java/modules/webapp/conf/web.xml

Modified: webservices/axis2/trunk/java/modules/adb/src/org/apache/axis2/databinding/utils/BeanUtil.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/adb/src/org/apache/axis2/databinding/utils/BeanUtil.java?view=diff&rev=504805&r1=504804&r2=504805
==============================================================================
--- webservices/axis2/trunk/java/modules/adb/src/org/apache/axis2/databinding/utils/BeanUtil.java (original)
+++ webservices/axis2/trunk/java/modules/adb/src/org/apache/axis2/databinding/utils/BeanUtil.java Wed Feb  7 22:41:16 2007
@@ -142,7 +142,17 @@
                                 }
                                 object.add(o == null ? null : SimpleTypeMapper.getStringValue(o));
                             }
+                        } else {
+                            if (elemntNameSpace != null) {
+                                object.add(new QName(elemntNameSpace.getNamespaceURI(),
+                                        propDesc.getName(), elemntNameSpace.getPrefix()));
+                            } else {
+                                object.add(new QName(beanName.getNamespaceURI(),
+                                        propDesc.getName(), beanName.getPrefix()));
+                            }
+                            object.add(value);
                         }
+
                     } else {
                         Object value [] = (Object[]) propDesc.getReadMethod().invoke(beanObject,
                                 null);
@@ -158,6 +168,15 @@
                                 }
                                 object.add(o);
                             }
+                        }else {
+                            if (elemntNameSpace != null) {
+                                object.add(new QName(elemntNameSpace.getNamespaceURI(),
+                                        propDesc.getName(), elemntNameSpace.getPrefix()));
+                            } else {
+                                object.add(new QName(beanName.getNamespaceURI(),
+                                        propDesc.getName(), beanName.getPrefix()));
+                            }
+                            object.add(value);
                         }
                     }
                 } else if (SimpleTypeMapper.isCollection(ptype)) {
@@ -191,7 +210,16 @@
                             }
                         }
 
-                    }
+                    }else {
+                             if (elemntNameSpace != null) {
+                                    object.add(new QName(elemntNameSpace.getNamespaceURI(),
+                                            propDesc.getName(), elemntNameSpace.getPrefix()));
+                                } else {
+                                    object.add(new QName(beanName.getNamespaceURI(),
+                                            propDesc.getName(), beanName.getPrefix()));
+                                }
+                                object.add(value);
+                        }
                 } else {
                     if (elemntNameSpace != null) {
                         object.add(new QName(elemntNameSpace.getNamespaceURI(),
@@ -570,8 +598,7 @@
                                          Object [] args,
                                          QName partName,
                                          boolean qualifed,
-                                         TypeTable typeTable,
-                                         boolean isCustomwsdl) {
+                                         TypeTable typeTable) {
         ArrayList objects;
         objects = new ArrayList();
         int argCount = 0;

Modified: webservices/axis2/trunk/java/modules/adb/src/org/apache/axis2/rpc/client/RPCServiceClient.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/adb/src/org/apache/axis2/rpc/client/RPCServiceClient.java?view=diff&rev=504805&r1=504804&r2=504805
==============================================================================
--- webservices/axis2/trunk/java/modules/adb/src/org/apache/axis2/rpc/client/RPCServiceClient.java (original)
+++ webservices/axis2/trunk/java/modules/adb/src/org/apache/axis2/rpc/client/RPCServiceClient.java Wed Feb  7 22:41:16 2007
@@ -63,7 +63,7 @@
      * @return Response OMElement
      */
     public OMElement invokeBlocking(QName opName, Object [] args) throws AxisFault {
-        OMElement omElement = BeanUtil.getOMElement(opName, args, null, false, null , false);
+        OMElement omElement = BeanUtil.getOMElement(opName, args, null, false, null );
         if (notNullService) {
             return super.sendReceive(opName, omElement);
         }
@@ -87,7 +87,7 @@
      */
 
     public Object[]  invokeBlocking(QName opName, Object [] args, Class [] returnTypes) throws AxisFault {
-        OMElement omElement = BeanUtil.getOMElement(opName, args, null, false, null , false);
+        OMElement omElement = BeanUtil.getOMElement(opName, args, null, false, null );
         OMElement response;
         if (notNullService) {
             response = super.sendReceive(opName, omElement);
@@ -112,7 +112,7 @@
                                   Object [] args,
                                   Callback callback)
             throws AxisFault {
-        OMElement omElement = BeanUtil.getOMElement(opName, args, null, false, null , false);
+        OMElement omElement = BeanUtil.getOMElement(opName, args, null, false, null );
         //call the underline implementation
         if (notNullService) {
             super.sendReceiveNonBlocking(opName, omElement, callback);
@@ -123,7 +123,7 @@
 
     public void invokeRobust(QName opName,
                              Object [] args) throws AxisFault {
-        OMElement omElement = BeanUtil.getOMElement(opName, args, null, false, null , false);
+        OMElement omElement = BeanUtil.getOMElement(opName, args, null, false, null );
         //call the underline implementation
         if (notNullService) {
             super.sendRobust(opName, omElement);

Modified: webservices/axis2/trunk/java/modules/adb/src/org/apache/axis2/rpc/receivers/RPCUtil.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/adb/src/org/apache/axis2/rpc/receivers/RPCUtil.java?view=diff&rev=504805&r1=504804&r2=504805
==============================================================================
--- webservices/axis2/trunk/java/modules/adb/src/org/apache/axis2/rpc/receivers/RPCUtil.java (original)
+++ webservices/axis2/trunk/java/modules/adb/src/org/apache/axis2/rpc/receivers/RPCUtil.java Wed Feb  7 22:41:16 2007
@@ -112,41 +112,36 @@
     public static OMElement getResponseElement(QName resname,
                                                Object [] objs,
                                                boolean qualified,
-                                               TypeTable typeTable,
-                                               boolean isCustomWsdl) {
+                                               TypeTable typeTable) {
         if (qualified) {
             return BeanUtil.getOMElement(resname, objs,
                     new QName(resname.getNamespaceURI(),
                             RETURN_WRAPPER,
                             resname.getPrefix()),
                     qualified,
-                    typeTable,
-                    isCustomWsdl);
+                    typeTable);
         } else {
             return BeanUtil.getOMElement(resname, objs,
                     new QName(RETURN_WRAPPER), qualified,
-                    typeTable,
-                    isCustomWsdl);
+                    typeTable);
         }
     }
 
     public static OMElement getResponseElementForArray(QName resname, Object [] objs,
                                                        boolean qualified,
-                                                       TypeTable typeTable, boolean isCustomWsdl) {
+                                                       TypeTable typeTable) {
         if (qualified) {
             return BeanUtil.getOMElement(resname, objs,
                     new QName(resname.getNamespaceURI(),
                             RETURN_WRAPPER,
                             resname.getPrefix()),
                     qualified,
-                    typeTable,
-                    isCustomWsdl);
+                    typeTable);
         } else {
             return BeanUtil.getOMElement(resname, objs,
                     new QName(RETURN_WRAPPER),
                     qualified,
-                    typeTable,
-                    isCustomWsdl);
+                    typeTable);
         }
     }
 
@@ -187,8 +182,7 @@
                 OMElement bodyChild = RPCUtil.getResponseElement(resName,
                         (Object[]) resObject,
                         service.isElementFormDefault(),
-                        service.getTypeTable(),
-                        service.isCustomWsld());
+                        service.getTypeTable());
                 envelope.getBody().addChild(bodyChild);
             } else {
                 if (resObject.getClass().isArray()) {
@@ -208,8 +202,7 @@
                             method.getName() + "Response",
                             elementQName.getPrefix());
                     OMElement bodyChild = RPCUtil.getResponseElementForArray(resName,
-                            objArray, service.isElementFormDefault(), service.getTypeTable(),
-                            service.isCustomWsld());
+                            objArray, service.isElementFormDefault(), service.getTypeTable());
                     envelope.getBody().addChild(bodyChild);
                 } else {
                     if (service.isElementFormDefault()) {

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/deployment/DeploymentEngine.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/deployment/DeploymentEngine.java?view=diff&rev=504805&r1=504804&r2=504805
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/deployment/DeploymentEngine.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/deployment/DeploymentEngine.java Wed Feb  7 22:41:16 2007
@@ -19,7 +19,6 @@
 
 import org.apache.axiom.om.OMElement;
 import org.apache.axis2.AxisFault;
-import org.apache.axis2.Constants;
 import org.apache.axis2.context.ConfigurationContext;
 import org.apache.axis2.deployment.repository.util.ArchiveFileData;
 import org.apache.axis2.deployment.repository.util.ArchiveReader;
@@ -224,6 +223,34 @@
                     new URL[]{servicesURL}, axisConfig.getServiceClassLoader(), antiJARLocking);
             String metainf = "meta-inf";
             serviceGroup.setServiceGroupClassLoader(serviceClassLoader);
+            //processing wsdl.list
+            InputStream wsdlfilesStream =serviceClassLoader.getResourceAsStream("meta-inf/wsdl.list");
+            if(wsdlfilesStream==null){
+                wsdlfilesStream =serviceClassLoader.getResourceAsStream("META-INF/wsdl.list");
+                if(wsdlfilesStream!=null){
+                    metainf = "META-INF";
+                }
+            }
+            HashMap servicesMap = new HashMap();
+            if(wsdlfilesStream!=null){
+                ArchiveReader reader = new ArchiveReader();
+                BufferedReader input = new BufferedReader(new InputStreamReader(wsdlfilesStream));
+                String line;
+                while ((line = input.readLine()) != null) {
+                    line = line.trim();
+                    if (line.length() > 0) {
+                        line = metainf + "/" + line;
+                        try {
+                            AxisService service =  reader.getAxisServiceFromWsdl(
+                                    serviceClassLoader.getResourceAsStream(line),
+                                    serviceClassLoader,line);
+                            servicesMap.put(service.getName(),service);
+                        } catch (Exception e) {
+                            throw new DeploymentException(e);
+                        }
+                    }
+                }
+            }
             InputStream servicexmlStream = serviceClassLoader.getResourceAsStream("META-INF/services.xml");
             if (servicexmlStream == null) {
                 servicexmlStream = serviceClassLoader.getResourceAsStream("meta-inf/services.xml");
@@ -266,7 +293,7 @@
                 serviceList.add(service);
                 return serviceList;
             } else if (TAG_SERVICE_GROUP.equals(elementName)) {
-                ServiceGroupBuilder groupBuilder = new ServiceGroupBuilder(rootElement, new HashMap(),
+                ServiceGroupBuilder groupBuilder = new ServiceGroupBuilder(rootElement, servicesMap,
                         configContext);
                 ArrayList servicList = groupBuilder.populateServiceGroup(serviceGroup);
                 Iterator serviceIterator = servicList.iterator();
@@ -474,14 +501,14 @@
     }
 
     /**
-     * @param file
+     * @param file ArchiveFileData
      */
     public void addWSToDeploy(ArchiveFileData file) {
         wsToDeploy.add(file);
     }
 
     /**
-     * @param file
+     * @param file WSInfo
      */
     public void addWSToUndeploy(WSInfo file) {
         wsToUnDeploy.add(file);
@@ -573,7 +600,6 @@
                                     axisConfig.getFaultyServices().put(currentArchiveFile.getFile().getAbsolutePath(),
                                             serviceStatus);
                                 }
-                                currentArchiveFile = null;
                             }
                             break;
                         case TYPE_MODULE :
@@ -633,7 +659,6 @@
                                     axisConfig.getFaultyModules().put(
                                             getAxisServiceName(currentArchiveFile.getName()), moduleStatus);
                                 }
-                                currentArchiveFile = null;
                             }
                             break;
                     }
@@ -650,6 +675,7 @@
 
     /**
      * Checks if the modules, referred by server.xml, exist or that they are deployed.
+     * @throws org.apache.axis2.AxisFault : If smt goes wrong
      */
     public void engageModules() throws AxisFault {
         for (Iterator iterator = axisConfig.getGlobalModules().iterator(); iterator.hasNext();) {
@@ -674,8 +700,8 @@
      * if it is valid , if something goes wrong you will be getting
      * DeploymentExeption
      *
-     * @param in
-     * @throws DeploymentException
+     * @param in : InputStream to axis2.xml
+     * @throws DeploymentException : If something goes wrong
      */
     public AxisConfiguration populateAxisConfiguration(InputStream in) throws DeploymentException {
         axisConfig = new AxisConfiguration();
@@ -693,6 +719,7 @@
 
     /**
      * Starts the Deployment engine to perform Hot deployment and so on.
+     * @param listener : RepositoryListener
      */
     protected void startSearch(RepositoryListener listener) {
         Scheduler scheduler = new Scheduler();

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/deployment/repository/util/ArchiveReader.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/deployment/repository/util/ArchiveReader.java?view=diff&rev=504805&r1=504804&r2=504805
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/deployment/repository/util/ArchiveReader.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/deployment/repository/util/ArchiveReader.java Wed Feb  7 22:41:16 2007
@@ -30,6 +30,8 @@
 import org.apache.axis2.deployment.ServiceGroupBuilder;
 import org.apache.axis2.deployment.resolver.AARBasedWSDLLocator;
 import org.apache.axis2.deployment.resolver.AARFileBasedURIResolver;
+import org.apache.axis2.deployment.resolver.WarBasedWSDLLocator;
+import org.apache.axis2.deployment.resolver.WarFileBasedURIResolver;
 import org.apache.axis2.description.AxisModule;
 import org.apache.axis2.description.AxisService;
 import org.apache.axis2.description.AxisServiceGroup;
@@ -336,6 +338,34 @@
             }
         }
         return servicesMap;
+    }
+
+    public AxisService getAxisServiceFromWsdl(InputStream in ,
+                                               ClassLoader loader, String wsdlUrl) throws Exception{
+//         ByteArrayInputStream in = new ByteArrayInputStream(out.toByteArray());
+
+        // now the question is which version of WSDL file this archive contains.
+        // lets check the namespace of the root element and decide. But since we are
+        // using axiom (dude, you are becoming handy here :)), we will not build the
+        // whole thing.
+        OMElement element = (OMElement) XMLUtils.toOM(in);
+        OMNamespace documentElementNS = element.getNamespace();
+        if (documentElementNS != null) {
+            WSDL11ToAxisServiceBuilder wsdlToAxisServiceBuilder ;
+            ByteArrayOutputStream out = new ByteArrayOutputStream();
+            element.serialize(out);
+            if (Constants.NS_URI_WSDL11.
+                    equals(documentElementNS.getNamespaceURI())) {
+                wsdlToAxisServiceBuilder = new WSDL11ToAxisServiceBuilder(new ByteArrayInputStream(out.toByteArray()), null, null);
+                wsdlToAxisServiceBuilder.setCustomWSLD4JResolver(new WarBasedWSDLLocator(wsdlUrl,loader,new ByteArrayInputStream(out.toByteArray())));
+                wsdlToAxisServiceBuilder.setCustomResolver(
+                        new WarFileBasedURIResolver(loader));
+                return wsdlToAxisServiceBuilder.populateService();
+            } else {
+                new DeploymentException(Messages.getMessage("invalidWSDLFound"));
+            }
+        }
+        return null;
     }
 
     public void processFilesInFolder(File folder, HashMap servicesMap) throws FileNotFoundException, XMLStreamException, DeploymentException {

Added: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/deployment/resolver/WarBasedWSDLLocator.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/deployment/resolver/WarBasedWSDLLocator.java?view=auto&rev=504805
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/deployment/resolver/WarBasedWSDLLocator.java (added)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/deployment/resolver/WarBasedWSDLLocator.java Wed Feb  7 22:41:16 2007
@@ -0,0 +1,84 @@
+package org.apache.axis2.deployment.resolver;
+
+import org.apache.ws.commons.schema.resolver.DefaultURIResolver;
+import org.apache.commons.logging.Log;
+import org.apache.commons.logging.LogFactory;
+import org.xml.sax.InputSource;
+
+import javax.wsdl.xml.WSDLLocator;
+import java.net.URI;
+import java.io.*;
+
+/*
+* Copyright 2004,2005 The Apache Software Foundation.
+*
+* Licensed under the Apache License, Version 2.0 (the "License");
+* you may not use this file except in compliance with the License.
+* You may obtain a copy of the License at
+*
+*      http://www.apache.org/licenses/LICENSE-2.0
+*
+* Unless required by applicable law or agreed to in writing, software
+* distributed under the License is distributed on an "AS IS" BASIS,
+* WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+* See the License for the specific language governing permissions and
+* limitations under the License.
+*
+*
+*/
+public class WarBasedWSDLLocator extends DefaultURIResolver implements WSDLLocator {
+     protected static final Log log = LogFactory
+            .getLog(WarBasedWSDLLocator.class);
+
+    private InputStream baseInputStream;
+    private URI lastImportLocation;
+    private String baseURI;
+    private ClassLoader classLoader;
+
+    public WarBasedWSDLLocator(String baseURI, ClassLoader classLoader, InputStream baseInputStream) {
+        this.baseURI = baseURI;
+        this.baseInputStream = baseInputStream;
+        this.classLoader = classLoader;
+    }
+
+    public InputSource getBaseInputSource() {
+        return new InputSource(baseInputStream);
+    }
+
+    /**
+     * @param parentLocation
+     * @param importLocation
+     */
+    public InputSource getImportInputSource(String parentLocation, String importLocation) {
+        lastImportLocation = URI.create(parentLocation).resolve(importLocation);
+
+        if (isAbsolute(importLocation)) {
+            return super.resolveEntity(
+                    null, importLocation, parentLocation);
+        } else {
+            String searchingStr = lastImportLocation.toString();
+            return new InputSource(classLoader.getResourceAsStream(searchingStr));
+        }
+    }
+
+    /**
+     * As for the zip there is no point in returning
+     * a base URI
+     */
+    public String getBaseURI() {
+        // we don't care
+        return baseURI;
+    }
+
+    /**
+     * returns the latest import
+     */
+    public String getLatestImportURI() {
+        //we don't care about this either
+        return lastImportLocation.toString();
+    }
+
+    public void close() {
+        //TODO: FIXME:
+    }
+}
\ No newline at end of file

Added: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/deployment/resolver/WarFileBasedURIResolver.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/deployment/resolver/WarFileBasedURIResolver.java?view=auto&rev=504805
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/deployment/resolver/WarFileBasedURIResolver.java (added)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/deployment/resolver/WarFileBasedURIResolver.java Wed Feb  7 22:41:16 2007
@@ -0,0 +1,59 @@
+package org.apache.axis2.deployment.resolver;
+
+import org.apache.ws.commons.schema.resolver.DefaultURIResolver;
+import org.apache.commons.logging.Log;
+import org.apache.commons.logging.LogFactory;
+import org.xml.sax.InputSource;
+
+import java.net.URI;
+
+/*
+* Copyright 2004,2005 The Apache Software Foundation.
+*
+* Licensed under the Apache License, Version 2.0 (the "License");
+* you may not use this file except in compliance with the License.
+* You may obtain a copy of the License at
+*
+*      http://www.apache.org/licenses/LICENSE-2.0
+*
+* Unless required by applicable law or agreed to in writing, software
+* distributed under the License is distributed on an "AS IS" BASIS,
+* WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+* See the License for the specific language governing permissions and
+* limitations under the License.
+*
+*
+*/
+public class WarFileBasedURIResolver extends DefaultURIResolver {
+
+    protected static final Log log = LogFactory
+            .getLog(WarFileBasedURIResolver.class);
+
+    private ClassLoader classLoader;
+
+    public WarFileBasedURIResolver(ClassLoader classLoader) {
+        this.classLoader = classLoader;
+    }
+
+    public InputSource resolveEntity(
+            String targetNamespace,
+            String schemaLocation,
+            String baseUri) {
+        //no issue with
+        if (isAbsolute(schemaLocation)) {
+            return super.resolveEntity(
+                    targetNamespace, schemaLocation, baseUri);
+        } else {
+            //validate
+            if ((baseUri == null || "".equals(baseUri)) && schemaLocation.startsWith("..")) {
+                throw new RuntimeException(
+                        "Unsupported schema location " + schemaLocation);
+            }
+
+            URI lastImportLocation = URI.create(baseUri).resolve(schemaLocation);
+            String searchingStr = lastImportLocation.toString();
+            return new InputSource(classLoader.getResourceAsStream(searchingStr));
+        }
+    }
+}
+

Modified: webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/description/WSDL11ToAxisServiceBuilder.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/description/WSDL11ToAxisServiceBuilder.java?view=diff&rev=504805&r1=504804&r2=504805
==============================================================================
--- webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/description/WSDL11ToAxisServiceBuilder.java (original)
+++ webservices/axis2/trunk/java/modules/kernel/src/org/apache/axis2/description/WSDL11ToAxisServiceBuilder.java Wed Feb  7 22:41:16 2007
@@ -215,6 +215,8 @@
             wsdlDefinitionParameter.setName(WSDLConstants.WSDL_4_J_DEFINITION);
             wsdlDefinitionParameter.setValue(wsdl4jDefinition);
             axisService.addParameter(wsdlDefinitionParameter);
+            axisService.setWsdlFound(true);
+            axisService.setCustomWsld(true);
 
             if (wsdl4jDefinition == null) {
                 return null;

Modified: webservices/axis2/trunk/java/modules/samples/servicelifecycle/src/sample/servicelifecycle/LibraryLifeCycle.java
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/samples/servicelifecycle/src/sample/servicelifecycle/LibraryLifeCycle.java?view=diff&rev=504805&r1=504804&r2=504805
==============================================================================
--- webservices/axis2/trunk/java/modules/samples/servicelifecycle/src/sample/servicelifecycle/LibraryLifeCycle.java (original)
+++ webservices/axis2/trunk/java/modules/samples/servicelifecycle/src/sample/servicelifecycle/LibraryLifeCycle.java Wed Feb  7 22:41:16 2007
@@ -82,17 +82,17 @@
             Book[] bookList = allBookList.getBookList();
             libElement.addChild(BeanUtil.getOMElement(
                     new QName(LibraryConstants.ALL_BOOK),
-                    bookList, new QName("book"), false, null, false));
+                    bookList, new QName("book"), false, null));
             libElement.addChild(BeanUtil.getOMElement(
                     new QName(LibraryConstants.AVAILABLE_BOOK),
-                    availableBookList.getBookList(), new QName("book"), false, null, false));
+                    availableBookList.getBookList(), new QName("book"), false, null));
             libElement.addChild(BeanUtil.getOMElement(
                     new QName(LibraryConstants.LEND_BOOK),
-                    lendBookList.getBookList(), new QName("book"), false, null, false));
+                    lendBookList.getBookList(), new QName("book"), false, null));
 
             libElement.addChild(BeanUtil.getOMElement(
                     new QName(LibraryConstants.USER_LIST),
-                    userList.getUsers(), new QName("user"), false, null,false));
+                    userList.getUsers(), new QName("user"), false, null));
 
             String tempDir = System.getProperty("java.io.tmpdir");
             File tempFile = new File(tempDir);

Modified: webservices/axis2/trunk/java/modules/webapp/conf/web.xml
URL: http://svn.apache.org/viewvc/webservices/axis2/trunk/java/modules/webapp/conf/web.xml?view=diff&rev=504805&r1=504804&r2=504805
==============================================================================
--- webservices/axis2/trunk/java/modules/webapp/conf/web.xml (original)
+++ webservices/axis2/trunk/java/modules/webapp/conf/web.xml Wed Feb  7 22:41:16 2007
@@ -58,11 +58,11 @@
 
     <error-page>
       <error-code>404</error-code>
-      <location>Error/error404.jsp</location>
+      <location>/axis2-web/Error/error404.jsp</location>
     </error-page>
 
     <error-page>
         <error-code>500</error-code>
-        <location>Error/error500.jsp</location>
+        <location>/axis2-web/Error/error500.jsp</location>
     </error-page>
 </web-app>



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