You are viewing a plain text version of this content. The canonical link for it is here.
Posted to axis-cvs@ws.apache.org by de...@apache.org on 2005/12/13 17:51:21 UTC

svn commit: r356539 [1/2] - in /webservices/axis2/trunk/java/modules: codegen/src/org/apache/axis2/databinding/extensions/ codegen/src/org/apache/axis2/rpc/ codegen/src/org/apache/axis2/wsdl/template/java/ codegen/test/org/apache/axis2/rpc/ core/src/or...

Author: deepal
Date: Tue Dec 13 08:50:12 2005
New Revision: 356539

URL: http://svn.apache.org/viewcvs?rev=356539&view=rev
Log:
As we decided in the hackathon, I  removed all the WSDL implementation from Axis* and in the mean while made the following changes as well.
    1. Changed Service name from Qname to string
    2. Removed unused flow in AxisService, removed Deployment code that check service flows.
 4. Removing  BADSeviceXMLtest and its related xml

Removed:
    webservices/axis2/trunk/java/modules/core/test-resources/deployment/BadService.xml
    webservices/axis2/trunk/java/modules/core/test/org/apache/axis2/deployment/BadServerXMLTest.java
    webservices/axis2/trunk/java/modules/core/test/org/apache/axis2/deployment/BadServiceXMLTest.java
Modified:
    webservices/axis2/trunk/java/modules/codegen/src/org/apache/axis2/databinding/extensions/XMLBeansSchemaUtility.java
    webservices/axis2/trunk/java/modules/codegen/src/org/apache/axis2/rpc/RPCInOutMessageReceiver.java
    webservices/axis2/trunk/java/modules/codegen/src/org/apache/axis2/wsdl/template/java/InterfaceImplementationTemplate.xsl
    webservices/axis2/trunk/java/modules/codegen/test/org/apache/axis2/rpc/SimpleTest.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/client/Call.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/client/InOutMEPClient.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/client/MEPClient.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/client/WSDLMEPClientBuilder.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/context/ConfigurationContext.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/context/MessageContext.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/context/OperationContext.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/context/ServiceContext.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/context/ServiceGroupContext.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/deployment/DeploymentEngine.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/deployment/ServiceBuilder.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/deployment/ServiceGroupBuilder.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/deployment/repository/util/ArchiveReader.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/deployment/util/Utils.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/description/AxisDescWSDLComponentFactory.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/description/AxisOperation.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/description/AxisService.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/description/InOnlyAxisOperation.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/description/InOutAxisOperation.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/description/OutInAxisOperation.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/description/OutOnlyAxisOperation.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/engine/AxisConfiguration.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/receivers/AbstractMessageReceiver.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/receivers/RawXMLINOnlyMessageReceiver.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/transport/http/HTTPTransportReceiver.java
    webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/util/Utils.java
    webservices/axis2/trunk/java/modules/core/test/org/apache/axis2/context/ContextHierarchyTest.java
    webservices/axis2/trunk/java/modules/core/test/org/apache/axis2/context/OperationContextTest.java
    webservices/axis2/trunk/java/modules/core/test/org/apache/axis2/deployment/BuildERWithDeploymentTest.java
    webservices/axis2/trunk/java/modules/core/test/org/apache/axis2/description/RegistryTest.java
    webservices/axis2/trunk/java/modules/core/test/org/apache/axis2/engine/EnginePausingTest.java
    webservices/axis2/trunk/java/modules/core/test/org/apache/axis2/engine/EngineWithoutPhaseResolvingTest.java
    webservices/axis2/trunk/java/modules/core/test/org/apache/axis2/engine/MessageContextTest.java
    webservices/axis2/trunk/java/modules/core/test/org/apache/axis2/engine/ModuleConfigTest.java
    webservices/axis2/trunk/java/modules/core/test/org/apache/axis2/engine/ParameterAddTest.java
    webservices/axis2/trunk/java/modules/integration/src/test/interop/whitemesa/round1/Round1Client.java
    webservices/axis2/trunk/java/modules/integration/src/test/interop/whitemesa/round2/SunRound2Client.java
    webservices/axis2/trunk/java/modules/integration/src/test/interop/whitemesa/round3/SunRound3Client.java
    webservices/axis2/trunk/java/modules/integration/test/org/apache/axis2/engine/MessageContextInjectionTest.java
    webservices/axis2/trunk/java/modules/integration/test/org/apache/axis2/engine/MessageWithServerTest.java
    webservices/axis2/trunk/java/modules/integration/test/org/apache/axis2/engine/OneWayRawXMLTest.java
    webservices/axis2/trunk/java/modules/integration/test/org/apache/axis2/engine/util/MyInOutMEPClient.java
    webservices/axis2/trunk/java/modules/integration/test/org/apache/axis2/integration/UtilServer.java
    webservices/axis2/trunk/java/modules/integration/test/org/apache/axis2/jms/JMSEchoRawXMLTest.java
    webservices/axis2/trunk/java/modules/integration/test/org/apache/axis2/mail/MailCharSetEncodingTest.java
    webservices/axis2/trunk/java/modules/integration/test/org/apache/axis2/mail/MailOneWayRawXMLTest.java
    webservices/axis2/trunk/java/modules/integration/test/org/apache/axis2/mail/MailRequestResponseRawXMLTest.java
    webservices/axis2/trunk/java/modules/integration/test/org/apache/axis2/mail/MailetRequestResponceRawXMLTest.java
    webservices/axis2/trunk/java/modules/integration/test/org/apache/axis2/mtom/EchoRawMTOMFaultReportTest.java
    webservices/axis2/trunk/java/modules/integration/test/org/apache/axis2/processingModel/SoapProcessingModelTest.java
    webservices/axis2/trunk/java/modules/integration/test/org/apache/axis2/rpc/MultirefTest.java
    webservices/axis2/trunk/java/modules/integration/test/org/apache/axis2/rpc/RPCCallTest.java
    webservices/axis2/trunk/java/modules/integration/test/org/apache/axis2/swa/EchoRawSwATest.java
    webservices/axis2/trunk/java/modules/integration/test/org/apache/axis2/tcp/TCPEchoRawXMLTest.java
    webservices/axis2/trunk/java/modules/samples/src/sample/amazon/search/AsynchronousClient.java
    webservices/axis2/trunk/java/modules/samples/src/sample/amazon/search/ClientUtil.java
    webservices/axis2/trunk/java/modules/samples/src/sample/google/search/AsynchronousClient.java
    webservices/axis2/trunk/java/modules/samples/src/sample/google/search/ClientUtil.java
    webservices/axis2/trunk/java/modules/security/interop/org/apache/axis2/security/InteropScenarioClient.java

Modified: webservices/axis2/trunk/java/modules/codegen/src/org/apache/axis2/databinding/extensions/XMLBeansSchemaUtility.java
URL: http://svn.apache.org/viewcvs/webservices/axis2/trunk/java/modules/codegen/src/org/apache/axis2/databinding/extensions/XMLBeansSchemaUtility.java?rev=356539&r1=356538&r2=356539&view=diff
==============================================================================
--- webservices/axis2/trunk/java/modules/codegen/src/org/apache/axis2/databinding/extensions/XMLBeansSchemaUtility.java (original)
+++ webservices/axis2/trunk/java/modules/codegen/src/org/apache/axis2/databinding/extensions/XMLBeansSchemaUtility.java Tue Dec 13 08:50:12 2005
@@ -179,7 +179,7 @@
 
             // create PortType with class name
             PortType portType = new PortTypeImpl();
-            portType.setQName(axisService.getName());
+            portType.setQName(new QName(axisService.getName()));
             definition.addPortType(portType);
             portType.setUndefined(false);
 

Modified: webservices/axis2/trunk/java/modules/codegen/src/org/apache/axis2/rpc/RPCInOutMessageReceiver.java
URL: http://svn.apache.org/viewcvs/webservices/axis2/trunk/java/modules/codegen/src/org/apache/axis2/rpc/RPCInOutMessageReceiver.java?rev=356539&r1=356538&r2=356539&view=diff
==============================================================================
--- webservices/axis2/trunk/java/modules/codegen/src/org/apache/axis2/rpc/RPCInOutMessageReceiver.java (original)
+++ webservices/axis2/trunk/java/modules/codegen/src/org/apache/axis2/rpc/RPCInOutMessageReceiver.java Tue Dec 13 08:50:12 2005
@@ -51,7 +51,9 @@
          */
         OperationContext oc = inMessage.getOperationContext();
         AxisOperation axisOperation = oc.getAxisOperation();
-        RPCMethod method = (RPCMethod)axisOperation.getMetadataBag().get(RPCMETHOD_PROPERTY);
+        //soryy , I removed WSDL infor from AxisOperation
+//        RPCMethod method = (RPCMethod)axisOperation.getMetadataBag().get(RPCMETHOD_PROPERTY);
+        RPCMethod method = (RPCMethod) axisOperation.getParameter(RPCMETHOD_PROPERTY).getValue();
         if (method == null) {
             throw new AxisFault("Couldn't find RPCMethod in AxisOperation");
         }
@@ -71,7 +73,7 @@
         arguments = new Object [method.getNumInParams()];
         Iterator params = method.getInParams();
         for (int i = 0; i < arguments.length; i++) {
-            RPCParameter param = (RPCParameter)params.next();
+            RPCParameter param = (RPCParameter) params.next();
             arguments[i] = param.getValue(values);
         }
 

Modified: webservices/axis2/trunk/java/modules/codegen/src/org/apache/axis2/wsdl/template/java/InterfaceImplementationTemplate.xsl
URL: http://svn.apache.org/viewcvs/webservices/axis2/trunk/java/modules/codegen/src/org/apache/axis2/wsdl/template/java/InterfaceImplementationTemplate.xsl?rev=356539&r1=356538&r2=356539&view=diff
==============================================================================
--- webservices/axis2/trunk/java/modules/codegen/src/org/apache/axis2/wsdl/template/java/InterfaceImplementationTemplate.xsl (original)
+++ webservices/axis2/trunk/java/modules/codegen/src/org/apache/axis2/wsdl/template/java/InterfaceImplementationTemplate.xsl Tue Dec 13 08:50:12 2005
@@ -31,7 +31,7 @@
         static{
 
            //creating the Service
-           _service = new org.apache.axis2.description.AxisService(new javax.xml.namespace.QName("<xsl:value-of select="@namespace"/>","<xsl:value-of select="@servicename"/>"));
+           _service = new org.apache.axis2.description.AxisService("<xsl:value-of select="@servicename"/>");
 
            //creating the operations
            org.apache.axis2.description.AxisOperation __operation;
@@ -51,7 +51,7 @@
 		    //creating the configuration
            _configurationContext = new org.apache.axis2.context.ConfigurationContextFactory().buildClientConfigurationContext(axis2Home);
            _configurationContext.getAxisConfiguration().addService(_service);
-           _serviceContext =new org.apache.axis2.context.ServiceGroupContext(_configurationContext, _service.getParent()).getServiceContext(_service.getName().getLocalPart());
+           _serviceContext =new org.apache.axis2.context.ServiceGroupContext(_configurationContext, _service.getParent()).getServiceContext(_service.getName());
            _clientOptions.setTo(new org.apache.axis2.addressing.EndpointReference(targetEndpoint));
 
         <!--  Set the soap version depending on the binding. Default is 1.1 so don't set anything for that case-->

Modified: webservices/axis2/trunk/java/modules/codegen/test/org/apache/axis2/rpc/SimpleTest.java
URL: http://svn.apache.org/viewcvs/webservices/axis2/trunk/java/modules/codegen/test/org/apache/axis2/rpc/SimpleTest.java?rev=356539&r1=356538&r2=356539&view=diff
==============================================================================
--- webservices/axis2/trunk/java/modules/codegen/test/org/apache/axis2/rpc/SimpleTest.java (original)
+++ webservices/axis2/trunk/java/modules/codegen/test/org/apache/axis2/rpc/SimpleTest.java Tue Dec 13 08:50:12 2005
@@ -25,12 +25,7 @@
 import org.apache.axis2.databinding.deserializers.SimpleDeserializerFactory;
 import org.apache.axis2.databinding.serializers.CollectionSerializer;
 import org.apache.axis2.databinding.serializers.SimpleSerializer;
-import org.apache.axis2.description.AxisOperation;
-import org.apache.axis2.description.AxisService;
-import org.apache.axis2.description.InOutAxisOperation;
-import org.apache.axis2.description.ParameterImpl;
-import org.apache.axis2.description.TransportInDescription;
-import org.apache.axis2.description.TransportOutDescription;
+import org.apache.axis2.description.*;
 import org.apache.axis2.engine.AxisConfiguration;
 import org.apache.axis2.om.OMAbstractFactory;
 import org.apache.axis2.receivers.AbstractMessageReceiver;
@@ -150,14 +145,17 @@
 
         LocalTransportReceiver.CONFIG_CONTEXT = new ConfigurationContext(config);
 
-        service = new AxisService(new QName("testService"));
+        service = new AxisService("testService");
         service.addParameter(
                 new ParameterImpl(AbstractMessageReceiver.SERVICE_CLASS,
                         Test.class.getName()));
         AxisOperation axisOperation = new InOutAxisOperation(new QName(methodName));
         axisOperation.setMessageReceiver(new RPCInOutMessageReceiver());
-        axisOperation.getMetadataBag().put(RPCInOutMessageReceiver.RPCMETHOD_PROPERTY, method);
         service.addOperation(axisOperation);
+        Parameter paramter = new ParameterImpl();
+        paramter.setName(RPCInOutMessageReceiver.RPCMETHOD_PROPERTY);
+        paramter.setValue(method);
+        axisOperation.addParameter(paramter);
         service.setClassLoader(Thread.currentThread().getContextClassLoader());
         LocalTransportReceiver.CONFIG_CONTEXT.getAxisConfiguration()
                 .addService(service);

Modified: webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/client/Call.java
URL: http://svn.apache.org/viewcvs/webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/client/Call.java?rev=356539&r1=356538&r2=356539&view=diff
==============================================================================
--- webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/client/Call.java (original)
+++ webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/client/Call.java Tue Dec 13 08:50:12 2005
@@ -172,7 +172,8 @@
 
         super.assumeServiceContext(clientHome);
         AxisService axisService = serviceContext.getAxisService();
-        axisOperationTemplate = new OutInAxisOperation(new QName("TemplateOperation"));
+        axisOperationTemplate = new OutInAxisOperation();
+        axisOperationTemplate.setName(new QName("TemplateOperation"));
 
         AxisConfiguration axisConfiguration = serviceContext.getConfigurationContext().getAxisConfiguration();
         PhasesInfo info = axisConfiguration.getPhasesInfo();

Modified: webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/client/InOutMEPClient.java
URL: http://svn.apache.org/viewcvs/webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/client/InOutMEPClient.java?rev=356539&r1=356538&r2=356539&view=diff
==============================================================================
--- webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/client/InOutMEPClient.java (original)
+++ webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/client/InOutMEPClient.java Tue Dec 13 08:50:12 2005
@@ -226,7 +226,7 @@
                 // Note that this will only change the replyTo Address property in the replyTo EPR
                 EndpointReference replyToFromTransport = ListenerManager.replyToEPR(
                         serviceContext.getConfigurationContext(),
-                        serviceContext.getAxisService().getName().getLocalPart()
+                        serviceContext.getAxisService().getName()
                                 + "/"
                                 + axisop.getName().getLocalPart(),
                         clientOptions.getListenerTransport().getName().getLocalPart());
@@ -312,7 +312,7 @@
                         .getTransportIn(clientOptions.getSenderTransport().getName()));
             }
         }
-            
+
         if (msgctx.getTransportIn() == null) {
             msgctx.setTransportIn(clientOptions.getListenerTransport());
         }

Modified: webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/client/MEPClient.java
URL: http://svn.apache.org/viewcvs/webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/client/MEPClient.java?rev=356539&r1=356538&r2=356539&view=diff
==============================================================================
--- webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/client/MEPClient.java (original)
+++ webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/client/MEPClient.java Tue Dec 13 08:50:12 2005
@@ -16,19 +16,10 @@
 
 package org.apache.axis2.client;
 
-import java.util.ArrayList;
-import java.util.List;
-
-import javax.xml.namespace.QName;
-
 import org.apache.axis2.AxisFault;
 import org.apache.axis2.Constants;
 import org.apache.axis2.addressing.EndpointReference;
-import org.apache.axis2.context.ConfigurationContext;
-import org.apache.axis2.context.ConfigurationContextFactory;
-import org.apache.axis2.context.MessageContext;
-import org.apache.axis2.context.ServiceContext;
-import org.apache.axis2.context.ServiceGroupContext;
+import org.apache.axis2.context.*;
 import org.apache.axis2.description.AxisOperation;
 import org.apache.axis2.description.AxisService;
 import org.apache.axis2.description.TransportOutDescription;
@@ -36,13 +27,13 @@
 import org.apache.axis2.i18n.Messages;
 import org.apache.axis2.om.OMAbstractFactory;
 import org.apache.axis2.om.OMElement;
-import org.apache.axis2.soap.SOAP11Constants;
-import org.apache.axis2.soap.SOAP12Constants;
-import org.apache.axis2.soap.SOAPEnvelope;
-import org.apache.axis2.soap.SOAPFactory;
-import org.apache.axis2.soap.SOAPHeader;
+import org.apache.axis2.soap.*;
 import org.apache.axis2.util.UUIDGenerator;
 
+import javax.xml.namespace.QName;
+import java.util.ArrayList;
+import java.util.List;
+
 /**
  * This is the super class for all the MEPClients.
  */
@@ -145,7 +136,7 @@
     }
 
     protected void addUserAddedSOAPHeaders(MessageContext msgCtx,
-            Options options) {
+                                           Options options) {
         if (soapHeaderList != null && soapHeaderList.size() > 0
                 && msgCtx.getEnvelope() != null) {
             SOAPFactory soapFactory;
@@ -168,7 +159,7 @@
 
     /**
      * Prepares the SOAPEnvelope using the payload.
-     * 
+     *
      * @param toSend
      * @return
      * @throws AxisFault
@@ -189,7 +180,7 @@
     /**
      * Infers the transport by looking at the URL. The URL can be http:// tcp://
      * mail:// local://.
-     * 
+     *
      * @param epr
      * @return
      * @throws AxisFault
@@ -216,7 +207,7 @@
         if (transport != null) {
             return serviceContext.getConfigurationContext()
                     .getAxisConfiguration().getTransportOut(
-                            new QName(transport));
+                    new QName(transport));
 
         } else {
             throw new AxisFault(Messages.getMessage("cannotInferTransport"));
@@ -226,7 +217,7 @@
 
     /**
      * Creates SOAPEvelope(in terms of version) from the values set.
-     * 
+     *
      * @return
      * @throws AxisFault
      */
@@ -259,7 +250,7 @@
      * deployment and known to Axis Engine). If not, an exception will be
      * thrown. To be enabled, the modules are added to the
      * AXIS2_REPOSITORY/modules directory.
-     * 
+     *
      * @param name
      * @throws AxisFault
      */
@@ -292,24 +283,22 @@
     /**
      * Assumes the values for the ConfigurationContext and ServiceContext to
      * make the NON WSDL cases simple.
-     * 
+     *
      * @throws AxisFault
      */
     protected void assumeServiceContext(String clientHome) throws AxisFault {
         ConfigurationContext configurationContext = new ConfigurationContextFactory()
                 .buildClientConfigurationContext(clientHome);
 
-        QName assumedServiceName = new QName(ANONYMOUS_SERVICE);
         AxisService axisService = configurationContext.getAxisConfiguration()
                 .getService(ANONYMOUS_SERVICE);
         if (axisService == null) {
             // we will assume a Service and operations
-            axisService = new AxisService(assumedServiceName);
+            axisService = new AxisService(ANONYMOUS_SERVICE);
         }
         configurationContext.getAxisConfiguration().addService(axisService);
         serviceContext = new ServiceGroupContext(configurationContext,
-                axisService.getParent()).getServiceContext(assumedServiceName
-                .getLocalPart());
+                axisService.getParent()).getServiceContext(ANONYMOUS_SERVICE);
     }
 
     public Options getClientOptions() {
@@ -319,7 +308,7 @@
     /**
      * User will set all the options and parameters for this invocation using
      * this.
-     * 
+     *
      * @param clientOptions
      * @see Options for more details.
      */
@@ -333,7 +322,7 @@
      * only one text. <code><pre>
      *    &lt;HeaderBlockName&gt;your text&lt;/HeaderBlockName&gt;
      * </pre></code>. A more flexible way is to use addSOAPHeader(OMElement).
-     * 
+     *
      * @param soapHeaderQName
      * @param soapHeaderText
      */
@@ -349,7 +338,7 @@
 
     /**
      * Allows users to add a SOAP header block.
-     * 
+     *
      * @param soapHeaderBlock
      */
     public void addSOAPHeader(OMElement soapHeaderBlock) {
@@ -392,7 +381,7 @@
                     clientOptions
                             .setSenderTransport(axisConfig
                                     .getTransportOut(new QName(
-                                            senderTrasportProtocol)));
+                                    senderTrasportProtocol)));
                 }
             }
             if (this.clientOptions.getSenderTransport() == null) {

Modified: webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/client/WSDLMEPClientBuilder.java
URL: http://svn.apache.org/viewcvs/webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/client/WSDLMEPClientBuilder.java?rev=356539&r1=356538&r2=356539&view=diff
==============================================================================
--- webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/client/WSDLMEPClientBuilder.java (original)
+++ webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/client/WSDLMEPClientBuilder.java Tue Dec 13 08:50:12 2005
@@ -70,7 +70,7 @@
 	}
 	
 	public MEPClient createMEPClient(QName endpointname,String operationname) throws AxisFault{
-		return createMEPClient(null,endpointname,operationname);
+        return createMEPClient(null,endpointname,operationname);
 	}
 	public MEPClient createMEPClient(String operationname) throws AxisFault{
 		return createMEPClient(null,null,operationname);
@@ -81,7 +81,7 @@
 			throw new AxisFault("You need to call public void defineDescription(URL wsdlurl before this method)");
 		}
 		WSDLService service = findService(servicename);
-		AxisService serviceDesc = new AxisService(service);
+		AxisService serviceDesc = new AxisService();
 		
 		WSDLEndpoint endpoint = findEndpoint(endpointname,service);
 		EndpointReference toepr = null;

Modified: webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/context/ConfigurationContext.java
URL: http://svn.apache.org/viewcvs/webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/context/ConfigurationContext.java?rev=356539&r1=356538&r2=356539&view=diff
==============================================================================
--- webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/context/ConfigurationContext.java (original)
+++ webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/context/ConfigurationContext.java Tue Dec 13 08:50:12 2005
@@ -25,11 +25,7 @@
 
 import javax.xml.namespace.QName;
 import java.io.File;
-import java.io.IOException;
-import java.io.ObjectInputStream;
-import java.io.ObjectOutputStream;
 import java.util.HashMap;
-import java.util.Iterator;
 import java.util.Map;
 
 /**
@@ -120,6 +116,7 @@
 
     /**
      * Returns the thread factory.
+     *
      * @return Returns configuration specific thread pool
      */
     public ThreadFactory getThreadPool() {
@@ -131,14 +128,15 @@
 
     /**
      * Sets the thread factory.
+     *
      * @param pool
      */
-    public void setThreadPool(ThreadFactory pool) throws AxisFault{
-    	  if (threadPool == null) {
-			threadPool = pool;
-		} else {
-			throw new AxisFault("Thread pool already set.");
-		}
+    public void setThreadPool(ThreadFactory pool) throws AxisFault {
+        if (threadPool == null) {
+            threadPool = pool;
+        } else {
+            throw new AxisFault("Thread pool already set.");
+        }
 
     }
 
@@ -186,8 +184,7 @@
         if (!isNull(serviceGroupContextId) && serviceGroupContextMap.get(serviceGroupContextId) != null) {
             // SGC is already there
             serviceGroupContext = (ServiceGroupContext) serviceGroupContextMap.get(serviceGroupContextId);
-            serviceContext = serviceGroupContext.getServiceContext(messageContext.getAxisService().getName().
-                    getLocalPart());
+            serviceContext = serviceGroupContext.getServiceContext(messageContext.getAxisService().getName());
         } else {
             // either the key is null or no SGC is found from the give key
             if (isNull(serviceGroupContextId)) {
@@ -197,10 +194,9 @@
             if (messageContext.getAxisService() != null) {
                 AxisServiceGroup axisServiceGroup =
                         messageContext.getAxisService().getParent();
-                serviceGroupContext = new ServiceGroupContext (this, axisServiceGroup);
+                serviceGroupContext = new ServiceGroupContext(this, axisServiceGroup);
                 serviceContext = serviceGroupContext.getServiceContext(
-                        messageContext.getAxisService().getName().
-                                getLocalPart());
+                        messageContext.getAxisService().getName());
                 //set the serviceGroupContextID
                 serviceGroupContext.setId(serviceGroupContextId);
                 this.registerServiceGroupContext(serviceGroupContext);
@@ -224,8 +220,8 @@
         }
     }
 
-    public ServiceGroupContext getServiceGroupContext(String serviceGroupContextId){
-        if(serviceGroupContextMap != null){
+    public ServiceGroupContext getServiceGroupContext(String serviceGroupContextId) {
+        if (serviceGroupContextMap != null) {
             return (ServiceGroupContext) serviceGroupContextMap.get(serviceGroupContextId);
         }
         return null;
@@ -237,10 +233,11 @@
 
     /**
      * Gets all service groups in the system.
+     *
      * @return Returns hashmap of ServiceGroupContexts.
      */
-    public HashMap getServiceGroupContexts(){
-        return (HashMap)serviceGroupContextMap;
+    public HashMap getServiceGroupContexts() {
+        return (HashMap) serviceGroupContextMap;
     }
 
 }

Modified: webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/context/MessageContext.java
URL: http://svn.apache.org/viewcvs/webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/context/MessageContext.java?rev=356539&r1=356538&r2=356539&view=diff
==============================================================================
--- webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/context/MessageContext.java (original)
+++ webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/context/MessageContext.java Tue Dec 13 08:50:12 2005
@@ -131,11 +131,6 @@
     private boolean serverSide;
 
     /**
-     * Field messageID
-     */
-    private String messageID;
-
-    /**
      * Field newThreadRequired
      */
     private boolean newThreadRequired = false;
@@ -167,8 +162,6 @@
     private boolean doingMTOM = false;
     //Are we doing REST now?
     private boolean doingREST = false;
-    //Rest through GET of HTTP
-    private boolean doRESTthroughPOST = true;
 
     private boolean isSOAP11 = true;
 
@@ -183,7 +176,7 @@
 
     String serviceGroupId = null;
 
-    QName serviceDescName = null;
+    String axisServiceName = null;
 
     QName axisOperationName = null;
 
@@ -192,19 +185,16 @@
      * transport in/out
      *
      * @param engineContext
-     * @throws AxisFault
      */
 
-    public MessageContext(ConfigurationContext engineContext)
-            throws AxisFault {
+    public MessageContext(ConfigurationContext engineContext) {
         this(engineContext, null, null, null);
     }
 
     public MessageContext(
             ConfigurationContext engineContext,
             TransportInDescription transportIn,
-            TransportOutDescription transportOut)
-            throws AxisFault {
+            TransportOutDescription transportOut) {
         this(engineContext, null, transportIn, transportOut);
         this.transportInName = transportIn.getName();
         this.transportOutname = transportOut.getName();
@@ -214,15 +204,13 @@
      * @param sessionContext
      * @param transportIn
      * @param transportOut
-     * @throws AxisFault
      */
 
     public MessageContext(
             ConfigurationContext engineContext,
             SessionContext sessionContext,
             TransportInDescription transportIn,
-            TransportOutDescription transportOut)
-            throws AxisFault {
+            TransportOutDescription transportOut) {
         super(null);
 
         if (sessionContext == null) {
@@ -681,8 +669,8 @@
      * @return Parameter <code>Parameter</code>
      */
     public Parameter getModuleParameter(String key, String moduleName, HandlerDescription handler) {
-        Parameter param = null;
-        ModuleConfiguration moduleConfig = null;
+        Parameter param;
+        ModuleConfiguration moduleConfig;
         if (getAxisOperation() != null) {
             AxisOperation opDesc = getAxisOperation();
             moduleConfig = opDesc.getModuleConfig(new QName(moduleName));
@@ -729,7 +717,7 @@
             }
         }
         AxisConfiguration baseConfig = configurationContext.getAxisConfiguration();
-        moduleConfig = ((AxisConfiguration) baseConfig).getModuleConfig(new QName(moduleName));
+        moduleConfig = baseConfig.getModuleConfig(new QName(moduleName));
         if (moduleConfig != null) {
             param = moduleConfig.getParameter(key);
             if (param != null) {
@@ -879,7 +867,7 @@
     public void setAxisService(AxisService axisService) {
         this.axisService = axisService;
         if (axisService != null)
-            this.serviceDescName = axisService.getName();
+            this.axisServiceName = axisService.getName();
     }
 
     public AxisServiceGroup getAxisServiceGroup() {

Modified: webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/context/OperationContext.java
URL: http://svn.apache.org/viewcvs/webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/context/OperationContext.java?rev=356539&r1=356538&r2=356539&view=diff
==============================================================================
--- webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/context/OperationContext.java (original)
+++ webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/context/OperationContext.java Tue Dec 13 08:50:12 2005
@@ -18,13 +18,7 @@
 
 import org.apache.axis2.AxisFault;
 import org.apache.axis2.description.AxisOperation;
-import org.apache.axis2.description.AxisService;
-import org.apache.axis2.engine.AxisConfiguration;
 
-import javax.xml.namespace.QName;
-import java.io.IOException;
-import java.io.ObjectInputStream;
-import java.io.ObjectOutputStream;
 import java.util.HashMap;
 import java.util.Iterator;
 import java.util.Map;
@@ -57,7 +51,6 @@
     // AxisOperation must be one of the 8 predefined ones in WSDL 2.0.
     private transient AxisOperation axisOperation;
 
-    private int operationMEP;
 
     private boolean isComplete = false;
 
@@ -65,10 +58,6 @@
     // the EngineContext. We're caching it here for faster acccess.
     private Map operationContextMap;
 
-    private QName operationDescName = null;
-
-    private QName serviceDescName = null;
-
     /**
      * Constructs a new OperationContext.
      *
@@ -82,26 +71,14 @@
         super(serviceContext);
         this.messageContexts = new HashMap();
         this.axisOperation = axisOperation;
-        this.operationMEP = axisOperation.getAxisSpecifMEPConstant();
         this.operationContextMap = getServiceContext().getConfigurationContext()
                 .getOperationContextMap();
-
-        operationDescName = axisOperation.getName();
-        AxisService axisService = axisOperation.getParent();
-        if (axisService !=null)
-            serviceDescName = axisService.getName();
     }
 
     public OperationContext(AxisOperation axisOperation) {
         super(null);
         this.messageContexts = new HashMap();
         this.axisOperation = axisOperation;
-        this.operationMEP = axisOperation.getAxisSpecifMEPConstant();
-
-        operationDescName = axisOperation.getName();
-        AxisService axisService = axisOperation.getParent();
-        if (axisService !=null)
-            serviceDescName = axisService.getName();
     }
 
     /**
@@ -138,8 +115,8 @@
      * @param msgContext
      */
     public synchronized void addMessageContext(MessageContext msgContext) throws AxisFault {
-        if(axisOperation != null){
-            axisOperation.addMessageContext(msgContext,this);
+        if (axisOperation != null) {
+            axisOperation.addMessageContext(msgContext, this);
         }
     }
 
@@ -156,7 +133,6 @@
     /**
      * Checks to see if the MEP is complete. i.e. whether all the messages that
      * are associated with the MEP has arrived and MEP is complete.
-     *
      */
     public boolean isComplete() {
         return isComplete;
@@ -177,7 +153,7 @@
      * being complete due to the optional nature of the MEP.
      */
     public void cleanup() {
-        Iterator msgContexts =   messageContexts.values().iterator();
+        Iterator msgContexts = messageContexts.values().iterator();
         while (msgContexts.hasNext()) {
             MessageContext messageContext = (MessageContext) msgContexts.next();
             if (null != messageContext && operationContextMap != null) {

Modified: webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/context/ServiceContext.java
URL: http://svn.apache.org/viewcvs/webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/context/ServiceContext.java?rev=356539&r1=356538&r2=356539&view=diff
==============================================================================
--- webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/context/ServiceContext.java (original)
+++ webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/context/ServiceContext.java Tue Dec 13 08:50:12 2005
@@ -16,10 +16,8 @@
 
 package org.apache.axis2.context;
 
-import org.apache.axis2.AxisFault;
 import org.apache.axis2.description.AxisOperation;
 import org.apache.axis2.description.AxisService;
-import org.apache.axis2.engine.AxisConfiguration;
 
 import javax.xml.namespace.QName;
 
@@ -33,8 +31,6 @@
 
     private String serviceInstanceID;
 
-    private QName axisServiceName = null;
-
 
     public ServiceContext(
             AxisService serviceConfig,
@@ -43,8 +39,7 @@
         this.axisService = serviceConfig;
 
         if (serviceConfig != null) {
-            this.axisServiceName = serviceConfig.getName();
-            serviceInstanceID = serviceConfig.getName().getLocalPart();
+            serviceInstanceID = serviceConfig.getName();
         }
 
     }

Modified: webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/context/ServiceGroupContext.java
URL: http://svn.apache.org/viewcvs/webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/context/ServiceGroupContext.java?rev=356539&r1=356538&r2=356539&view=diff
==============================================================================
--- webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/context/ServiceGroupContext.java (original)
+++ webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/context/ServiceGroupContext.java Tue Dec 13 08:50:12 2005
@@ -16,10 +16,8 @@
 
 package org.apache.axis2.context;
 
-import org.apache.axis2.AxisFault;
 import org.apache.axis2.description.AxisService;
 import org.apache.axis2.description.AxisServiceGroup;
-import org.apache.axis2.engine.AxisConfiguration;
 
 import java.util.HashMap;
 import java.util.Iterator;
@@ -66,8 +64,8 @@
         while (services.hasNext()) {
             AxisService axisService = (AxisService) services.next();
             ServiceContext serviceContext = new ServiceContext(axisService, this);
-            String servicNams = axisService.getName().getLocalPart();
-            serviceContextMap.put(servicNams, serviceContext);
+            String serviceName = axisService.getName();
+            serviceContextMap.put(serviceName, serviceContext);
         }
     }
 

Modified: webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/deployment/DeploymentEngine.java
URL: http://svn.apache.org/viewcvs/webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/deployment/DeploymentEngine.java?rev=356539&r1=356538&r2=356539&view=diff
==============================================================================
--- webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/deployment/DeploymentEngine.java (original)
+++ webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/deployment/DeploymentEngine.java Tue Dec 13 08:50:12 2005
@@ -403,7 +403,6 @@
         Iterator services = serviceList.iterator();
         while (services.hasNext()) {
             AxisService axisService = (AxisService) services.next();
-            Utils.loadServiceProperties(axisService);
             axisService.setFileName(
                     currentArchiveFile.getFile().getAbsolutePath());
             serviceGroup.addService(axisService);
@@ -415,7 +414,7 @@
                 if (module == null) {
                     throw new DeploymentException(Messages.getMessage(
                             DeploymentErrorMsgs.BAD_MODULE_FROM_SERVICE,
-                            axisService.getName().getLocalPart(),
+                            axisService.getName(),
                             ((QName) list.get(i)).getLocalPart()));
                 }
                 axisService.engageModule(module, axisConfig);
@@ -692,7 +691,6 @@
 
             ServiceBuilder builder = new ServiceBuilder(serviceInputStream, axisConfig, axisService);
             builder.populateService(builder.buildOM());
-            Utils.loadServiceProperties(axisService);
         } catch (AxisFault axisFault) {
             throw new DeploymentException(axisFault);
         } catch (XMLStreamException e) {

Modified: webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/deployment/ServiceBuilder.java
URL: http://svn.apache.org/viewcvs/webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/deployment/ServiceBuilder.java?rev=356539&r1=356538&r2=356539&view=diff
==============================================================================
--- webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/deployment/ServiceBuilder.java (original)
+++ webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/deployment/ServiceBuilder.java Tue Dec 13 08:50:12 2005
@@ -18,21 +18,12 @@
 
 import org.apache.axis2.AxisFault;
 import org.apache.axis2.deployment.util.PhasesInfo;
-import org.apache.axis2.description.AxisMessage;
-import org.apache.axis2.description.AxisOperation;
-import org.apache.axis2.description.AxisOperationFactory;
-import org.apache.axis2.description.AxisService;
-import org.apache.axis2.description.InOutAxisOperation;
-import org.apache.axis2.description.ModuleConfiguration;
-import org.apache.axis2.description.Parameter;
-import org.apache.axis2.description.ParameterInclude;
+import org.apache.axis2.description.*;
 import org.apache.axis2.engine.AxisConfiguration;
 import org.apache.axis2.engine.MessageReceiver;
 import org.apache.axis2.i18n.Messages;
 import org.apache.axis2.om.OMAttribute;
 import org.apache.axis2.om.OMElement;
-import org.apache.wsdl.WSDLOperation;
-import org.apache.wsdl.impl.WSDLOperationImpl;
 
 import javax.xml.namespace.QName;
 import javax.xml.stream.XMLStreamException;
@@ -92,9 +83,9 @@
             } else {
                 OMAttribute serviceNameatt = service_element.getAttribute(
                         new QName(ATTNAME));
-                if(serviceNameatt != null) {
+                if (serviceNameatt != null) {
                     service.setAxisServiceName(serviceNameatt.getAttributeValue());
-                }                
+                }
             }
 
             //processing servicewide modules which required to engage gloabbly
@@ -102,31 +93,6 @@
                     new QName(MODULEST));
             processModuleRefs(moduleRefs);
 
-            //process INFLOW
-            OMElement inFlow = service_element.getFirstChildWithName(
-                    new QName(INFLOWST));
-            if (inFlow != null) {
-                service.setInFlow(processFlow(inFlow, service));
-            }
-
-            OMElement outFlow = service_element.getFirstChildWithName(
-                    new QName(OUTFLOWST));
-            if (outFlow != null) {
-                service.setOutFlow(processFlow(outFlow, service));
-            }
-
-            OMElement inFaultFlow = service_element.getFirstChildWithName(
-                    new QName(IN_FAILTFLOW));
-            if (inFaultFlow != null) {
-                service.setFaultInFlow(processFlow(inFaultFlow, service));
-            }
-
-            OMElement outFaultFlow = service_element.getFirstChildWithName(
-                    new QName(OUT_FAILTFLOW));
-            if (outFaultFlow != null) {
-                service.setFaultOutFlow(processFlow(outFaultFlow, service));
-            }
-
             //processing operations
             Iterator operationsIterator = service_element.getChildrenWithName(
                     new QName(OPRATIONST));
@@ -180,29 +146,16 @@
             }
 
             String opname = op_name_att.getAttributeValue();
-            WSDLOperation wsdlOperation = service.getWSDLOPOperation(new QName(opname));
-//            AxisOperation op_descrip = service.getOperation(new QName(opname));
             AxisOperation op_descrip;
-            if (wsdlOperation == null) {
-                if (mepurl == null) {
-                    // assumed MEP is in-out
-                    op_descrip = new InOutAxisOperation();
-                } else {
-                    op_descrip = AxisOperationFactory.getOperetionDescription(mepurl);
-                }
-//                op_descrip = new AxisOperation();
-                op_descrip.setName(new QName(opname));
-                log.info(Messages.getMessage(DeploymentErrorMsgs.OP_NOT_FOUN_IN_WSDL, opname));
+            if (mepurl == null) {
+                // assumed MEP is in-out
+                op_descrip = new InOutAxisOperation();
             } else {
-                //craeting operation from existing operation
-                String mep = wsdlOperation.getMessageExchangePattern();
-                if (mep == null) {
-                    op_descrip = new InOutAxisOperation(wsdlOperation);
-                } else {
-                    op_descrip = AxisOperationFactory.getOperetionDescription(mep);
-                    op_descrip.setWsdloperation((WSDLOperationImpl) wsdlOperation);
-                }
+                op_descrip = AxisOperationFactory.getOperetionDescription(mepurl);
             }
+//                op_descrip = new AxisOperation();
+            op_descrip.setName(new QName(opname));
+            log.info(Messages.getMessage(DeploymentErrorMsgs.OP_NOT_FOUN_IN_WSDL, opname));
 
             //Operation Parameters
             Iterator parameters = operation.getChildrenWithName(

Modified: webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/deployment/ServiceGroupBuilder.java
URL: http://svn.apache.org/viewcvs/webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/deployment/ServiceGroupBuilder.java?rev=356539&r1=356538&r2=356539&view=diff
==============================================================================
--- webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/deployment/ServiceGroupBuilder.java (original)
+++ webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/deployment/ServiceGroupBuilder.java Tue Dec 13 08:50:12 2005
@@ -74,8 +74,7 @@
                 } else {
                     AxisService axisService = (AxisService) wsdlServices.get(serviceName);
                     if (axisService == null) {
-                        axisService = new AxisService(new QName(serviceName));
-                        axisService.setName(new QName(serviceName));
+                        axisService = new AxisService(serviceName);
                     }
                     // the service that has to be deploy
                     axisService.setParent(axisServiceGroup);
@@ -88,7 +87,7 @@
         } catch (AxisFault e) {
             throw new DeploymentException(e);
         }
-     return serviceList;
+        return serviceList;
     }
 
     protected void processServiceModuleConfig(Iterator moduleConfigs,

Modified: webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/deployment/repository/util/ArchiveReader.java
URL: http://svn.apache.org/viewcvs/webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/deployment/repository/util/ArchiveReader.java?rev=356539&r1=356538&r2=356539&view=diff
==============================================================================
--- webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/deployment/repository/util/ArchiveReader.java (original)
+++ webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/deployment/repository/util/ArchiveReader.java Tue Dec 13 08:50:12 2005
@@ -16,14 +16,7 @@
 
 package org.apache.axis2.deployment.repository.util;
 
-import org.apache.axis2.deployment.DeploymentConstants;
-import org.apache.axis2.deployment.DeploymentEngine;
-import org.apache.axis2.deployment.DeploymentErrorMsgs;
-import org.apache.axis2.deployment.DeploymentException;
-import org.apache.axis2.deployment.DescriptionBuilder;
-import org.apache.axis2.deployment.ModuleBuilder;
-import org.apache.axis2.deployment.ServiceBuilder;
-import org.apache.axis2.deployment.ServiceGroupBuilder;
+import org.apache.axis2.deployment.*;
 import org.apache.axis2.description.AxisDescWSDLComponentFactory;
 import org.apache.axis2.description.AxisService;
 import org.apache.axis2.description.AxisServiceGroup;
@@ -76,8 +69,8 @@
                 // description we read in as we will be replacing them anyway.
                 WSDLServiceImpl serviceimpl = (WSDLServiceImpl)
                         womDescription.getServices().get(iterator.next());
-                AxisService service = new AxisService(serviceimpl);
-                service.setName(serviceimpl.getName());
+                AxisService service = new AxisService();
+                service.setName(serviceimpl.getName().getLocalPart());
                 service.setWSDLDefinition(wsdlVersionWrapper.getDefinition());
                 return service;
 //                depengine.getCurrentFileItem().addService(service);
@@ -115,7 +108,7 @@
                     if (fileName.endsWith(".wsdl") || fileName.endsWith(".WSDL")) {
                         InputStream in = new FileInputStream(file1);
                         AxisService service = processWSDLFile(in);
-                        servicesMap.put(service.getName().getLocalPart(), service);
+                        servicesMap.put(service.getName(), service);
                         try {
                             in.close();
                         } catch (IOException e) {
@@ -150,7 +143,7 @@
                         }
                         ByteArrayInputStream in = new ByteArrayInputStream(out.toByteArray());
                         AxisService service = processWSDLFile(in);
-                        servicesMap.put(service.getName().getLocalPart(), service);
+                        servicesMap.put(service.getName(), service);
                     }
                 }
                 try {
@@ -182,7 +175,6 @@
                                          AxisConfiguration axisConfig)
             throws DeploymentException {
         // get attribute values
-        boolean foundServiceXML = false;
         if (!extractService) {
             ZipInputStream zin;
             try {
@@ -190,19 +182,16 @@
                 ZipEntry entry;
                 while ((entry = zin.getNextEntry()) != null) {
                     if (entry.getName().equals(SERVICEXML)) {
-                        foundServiceXML = true;
                         axisServiceGroup.setServiceGroupName(DescriptionBuilder.getShortFileName(
                                 engine.getCurrentFileItem().getName()));
                         return buildServiceGroup(zin, engine, axisServiceGroup, wsdls, axisConfig);
                     }
                 }
                 //    zin.close();
-                if (!foundServiceXML) {
-                    throw new DeploymentException(
-                            Messages.getMessage(
-                                    DeploymentErrorMsgs.SERVICE_XML_NOT_FOUND,
-                                    filename));
-                }
+                throw new DeploymentException(
+                        Messages.getMessage(
+                                DeploymentErrorMsgs.SERVICE_XML_NOT_FOUND,
+                                filename));
             } catch (Exception e) {
                 throw new DeploymentException(e);
             }
@@ -226,7 +215,6 @@
                         Messages.getMessage(DeploymentErrorMsgs.SERVICE_XML_NOT_FOUND));
             }
         }
-        return null;
     }
 
     private ArrayList buildServiceGroup(InputStream zin, DeploymentEngine engine,
@@ -243,8 +231,7 @@
                     DescriptionBuilder.getShortFileName(engine.getCurrentFileItem().getName()));
             if (axisService == null) {
                 axisService = new AxisService(
-                        new QName(DescriptionBuilder.getShortFileName(
-                                engine.getCurrentFileItem().getName())));
+                        DescriptionBuilder.getShortFileName(engine.getCurrentFileItem().getName()));
             }
             axisService.setParent(axisServiceGroup);
             axisService.setClassLoader(engine.getCurrentFileItem().getClassLoader());

Modified: webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/deployment/util/Utils.java
URL: http://svn.apache.org/viewcvs/webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/deployment/util/Utils.java?rev=356539&r1=356538&r2=356539&view=diff
==============================================================================
--- webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/deployment/util/Utils.java (original)
+++ webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/deployment/util/Utils.java Tue Dec 13 08:50:12 2005
@@ -2,7 +2,6 @@
 
 import org.apache.axis2.AxisFault;
 import org.apache.axis2.deployment.DeploymentException;
-import org.apache.axis2.description.AxisService;
 import org.apache.axis2.description.Flow;
 import org.apache.axis2.description.HandlerDescription;
 import org.apache.axis2.engine.Handler;
@@ -74,37 +73,6 @@
             }
         }
         return null;
-    }
-
-    /**
-     * This method is used to fill the axis service , it dose loading service class and also the provider class
-     * and it will also load the service handlers
-     *
-     * @param axisService
-     * @throws org.apache.axis2.AxisFault
-     */
-    public static void loadServiceProperties(AxisService axisService) throws AxisFault {
-        Flow inflow = axisService.getInFlow();
-        ClassLoader cls = axisService.getClassLoader();
-        if (inflow != null) {
-            addFlowHandlers(inflow, cls);
-        }
-
-        Flow outFlow = axisService.getOutFlow();
-        if (outFlow != null) {
-            addFlowHandlers(outFlow, cls);
-        }
-
-        Flow faultInFlow = axisService.getFaultInFlow();
-        if (faultInFlow != null) {
-            addFlowHandlers(faultInFlow, cls);
-        }
-
-        Flow faultOutFlow = axisService.getFaultOutFlow();
-        if (faultOutFlow != null) {
-            addFlowHandlers(faultOutFlow, cls);
-        }
-        // axisService.setClassLoader(currentArchiveFile.getClassLoader());
     }
 
     public static void addFlowHandlers(Flow flow, ClassLoader clsLoader) throws AxisFault {

Modified: webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/description/AxisDescWSDLComponentFactory.java
URL: http://svn.apache.org/viewcvs/webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/description/AxisDescWSDLComponentFactory.java?rev=356539&r1=356538&r2=356539&view=diff
==============================================================================
--- webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/description/AxisDescWSDLComponentFactory.java (original)
+++ webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/description/AxisDescWSDLComponentFactory.java Tue Dec 13 08:50:12 2005
@@ -20,22 +20,7 @@
 import org.apache.wsdl.WSDLTypes;
 import org.apache.wsdl.extensions.ExtensionFactory;
 import org.apache.wsdl.extensions.impl.ExtensionFactoryImpl;
-import org.apache.wsdl.impl.MessageReferenceImpl;
-import org.apache.wsdl.impl.WSDLBindingFaultImpl;
-import org.apache.wsdl.impl.WSDLBindingImpl;
-import org.apache.wsdl.impl.WSDLBindingMessageReferenceImpl;
-import org.apache.wsdl.impl.WSDLBindingOperationImpl;
-import org.apache.wsdl.impl.WSDLDescriptionImpl;
-import org.apache.wsdl.impl.WSDLEndpointImpl;
-import org.apache.wsdl.impl.WSDLExtensibilityAttributeImpl;
-import org.apache.wsdl.impl.WSDLFaultReferenceImpl;
-import org.apache.wsdl.impl.WSDLFeatureImpl;
-import org.apache.wsdl.impl.WSDLImportImpl;
-import org.apache.wsdl.impl.WSDLIncludeImpl;
-import org.apache.wsdl.impl.WSDLInterfaceImpl;
-import org.apache.wsdl.impl.WSDLOperationImpl;
-import org.apache.wsdl.impl.WSDLPropertyImpl;
-import org.apache.wsdl.impl.WSDLTypesImpl;
+import org.apache.wsdl.impl.*;
 
 public class AxisDescWSDLComponentFactory implements WSDLComponentFactory {
 
@@ -46,7 +31,7 @@
 
 
     public WSDLService createService() {
-        return new AxisService();
+        return new WSDLServiceImpl();
     }
 
 

Modified: webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/description/AxisOperation.java
URL: http://svn.apache.org/viewcvs/webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/description/AxisOperation.java?rev=356539&r1=356538&r2=356539&view=diff
==============================================================================
--- webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/description/AxisOperation.java (original)
+++ webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/description/AxisOperation.java Tue Dec 13 08:50:12 2005
@@ -13,24 +13,13 @@
 import org.apache.axis2.phaseresolver.PhaseResolver;
 import org.apache.commons.logging.Log;
 import org.apache.commons.logging.LogFactory;
-import org.apache.wsdl.MessageReference;
 import org.apache.wsdl.WSDLConstants;
-import org.apache.wsdl.WSDLExtensibilityAttribute;
-import org.apache.wsdl.WSDLExtensibilityElement;
-import org.apache.wsdl.WSDLFaultReference;
-import org.apache.wsdl.WSDLFeature;
-import org.apache.wsdl.WSDLOperation;
-import org.apache.wsdl.WSDLProperty;
-import org.apache.wsdl.impl.WSDLOperationImpl;
-import org.w3c.dom.Document;
 
 import javax.xml.namespace.QName;
 import java.util.ArrayList;
 import java.util.Collection;
 import java.util.HashMap;
 import java.util.Iterator;
-import java.util.List;
-import java.util.Map;
 /*
 * Copyright 2004,2005 The Apache Software Foundation.
 *
@@ -51,20 +40,21 @@
 
 public abstract class AxisOperation implements
         ParameterInclude, DescriptionConstants,
-        WSDLConstants, WSDLOperation {
+        WSDLConstants {
+
+    public static final String STYLE_RPC = "rpc";
+    public static final String STYLE_DOC = "doc";
+    public static final String STYLE_MSG = "msg";
+
     private Log log = LogFactory.getLog(getClass());
 
     private MessageReceiver messageReceiver;
-//    private ArrayList remainingPhasesInFlow;
-//    private ArrayList phasesOutFlow;
-//    private ArrayList phasesInFaultFlow;
-//    private ArrayList phasesOutFaultFlow;
 
     private HashMap moduleConfigmap;
 
     private int mep = MEP_CONSTANT_INVALID;
 
-    private WSDLOperationImpl wsdloperation;
+    //  private WSDLOperationImpl wsdloperation;
 
     private AxisService parent;
     private ArrayList wsamappingList;
@@ -76,17 +66,20 @@
     //to store engaged modules
     private ArrayList engagedModules = new ArrayList();
 
+    //todo need to change name to String
+    private QName name;
+    //to store mepURL
+    private String mepURI;
 
-    public AxisOperation(WSDLOperation wsdloperation) {
-        this.wsdloperation = (WSDLOperationImpl) wsdloperation;
-        this.setMessageExchangePattern(MEP_URI_IN_OUT);
-        this.setComponentProperty(PARAMETER_KEY, new ParameterIncludeImpl());
-        modulerefs = new ArrayList();
-        moduleConfigmap = new HashMap();
-    }
+    private ParameterInclude parameterInclude;
+
+    private String style = STYLE_DOC;
 
     public AxisOperation() {
-        this(new WSDLOperationImpl());
+        mepURI = MEP_URI_IN_OUT;
+        parameterInclude = new ParameterIncludeImpl();
+        modulerefs = new ArrayList();
+        moduleConfigmap = new HashMap();
     }
 
     public AxisOperation(QName name) {
@@ -149,9 +142,7 @@
         if (isParameterLocked(param.getName())) {
             throw new AxisFault("Parmter is locked can not overide: " + param.getName());
         } else {
-            ParameterIncludeImpl paramInclude = (ParameterIncludeImpl) this
-                    .getComponentProperty(PARAMETER_KEY);
-            paramInclude.addParameter(param);
+            parameterInclude.addParameter(param);
         }
     }
 
@@ -161,15 +152,11 @@
      * @param name Name of the parameter
      */
     public Parameter getParameter(String name) {
-        ParameterIncludeImpl paramInclude = (ParameterIncludeImpl) this
-                .getComponentProperty(PARAMETER_KEY);
-        return paramInclude.getParameter(name);
+        return parameterInclude.getParameter(name);
     }
 
     public ArrayList getParameters() {
-        ParameterIncludeImpl paramInclude = (ParameterIncludeImpl) this
-                .getComponentProperty(PARAMETER_KEY);
-        return paramInclude.getParameters();
+        return parameterInclude.getParameters();
     }
 
     public MessageReceiver getMessageReceiver() {
@@ -177,9 +164,7 @@
     }
 
     public void deserializeParameters(OMElement parameterElement) throws AxisFault {
-        ParameterIncludeImpl paramInclude = (ParameterIncludeImpl) this
-                .getComponentProperty(PARAMETER_KEY);
-        paramInclude.deserializeParameters(parameterElement);
+        parameterInclude.deserializeParameters(parameterElement);
     }
 
     public void setMessageReceiver(MessageReceiver messageReceiver) {
@@ -225,6 +210,14 @@
 
     }
 
+    public String getMessageExchangePattern() {
+        return mepURI;
+    }
+
+    public void setMessageExchangePattern(String mepURI) {
+        this.mepURI = mepURI;
+    }
+
 
     public abstract ArrayList getPhasesInFaultFlow();
 
@@ -307,147 +300,15 @@
     public abstract void addMessageContext(MessageContext msgContext, OperationContext opContext)
             throws AxisFault;
 
-    public List getInfaults() {
-        return wsdloperation.getInfaults();
-    }
-
-    public void setInfaults(List infaults) {
-        wsdloperation.setInfaults(infaults);
-    }
-
-    public MessageReference getInputMessage() {
-        return wsdloperation.getInputMessage();
-    }
-
-    public void setInputMessage(MessageReference inputMessage) {
-        wsdloperation.setInputMessage(inputMessage);
-    }
-
-    public String getMessageExchangePattern() {
-        return wsdloperation.getMessageExchangePattern();
-    }
-
-    public void setMessageExchangePattern(String messageExchangePattern) {
-        wsdloperation.setMessageExchangePattern(messageExchangePattern);
-    }
 
     public QName getName() {
-        return wsdloperation.getName();
+        return name;
     }
 
     public void setName(QName name) {
-        wsdloperation.setName(name);
-    }
-
-    public List getOutfaults() {
-        return wsdloperation.getOutfaults();
-    }
-
-    public void setOutfaults(List outfaults) {
-        wsdloperation.setOutfaults(outfaults);
-    }
-
-    public MessageReference getOutputMessage() {
-        return wsdloperation.getOutputMessage();
-    }
-
-    public void setOutputMessage(MessageReference outputMessage) {
-        wsdloperation.setOutputMessage(outputMessage);
-    }
-
-    public boolean isSafe() {
-        return wsdloperation.isSafe();
-    }
-
-    public void setSafety(boolean safe) {
-        wsdloperation.setSafety(safe);
-    }
-
-    public String getStyle() {
-        return wsdloperation.getStyle();
-    }
-
-    public void setStyle(String style) {
-        wsdloperation.setStyle(style);
-    }
-
-    public String getTargetnamespace() {
-        return wsdloperation.getTargetnamespace();
+        this.name = name;
     }
 
-    public void addInFault(WSDLFaultReference inFault) {
-        wsdloperation.addInFault(inFault);
-    }
-
-    public void addOutFault(WSDLFaultReference outFault) {
-        wsdloperation.addOutFault(outFault);
-    }
-
-    public void addFeature(WSDLFeature feature) {
-        wsdloperation.addFeature(feature);
-    }
-
-    public List getFeatures() {
-        return wsdloperation.getFeatures();
-    }
-
-    public void addProperty(WSDLProperty wsdlProperty) {
-        wsdloperation.addProperty(wsdlProperty);
-    }
-
-    public List getProperties() {
-        return wsdloperation.getProperties();
-    }
-
-    public Document getDocumentation() {
-        return wsdloperation.getDocumentation();
-    }
-
-    public void setDocumentation(Document documentation) {
-        wsdloperation.setDocumentation(documentation);
-    }
-
-    public HashMap getComponentProperties() {
-        return wsdloperation.getComponentProperties();
-    }
-
-    public void setComponentProperties(HashMap properties) {
-        wsdloperation.setComponentProperties(properties);
-    }
-
-    public void setComponentProperty(Object key, Object obj) {
-        wsdloperation.setComponentProperty(key, obj);
-    }
-
-    public Object getComponentProperty(Object key) {
-        return wsdloperation.getComponentProperty(key);
-    }
-
-    public void addExtensibilityElement(WSDLExtensibilityElement element) {
-        wsdloperation.addExtensibilityElement(element);
-    }
-
-    public List getExtensibilityElements() {
-        return wsdloperation.getExtensibilityElements();
-    }
-
-    public void addExtensibleAttributes(WSDLExtensibilityAttribute attribute) {
-        wsdloperation.addExtensibleAttributes(attribute);
-    }
-
-    public List getExtensibilityAttributes() {
-        return wsdloperation.getExtensibilityAttributes();
-    }
-
-    public Map getMetadataBag() {
-        return wsdloperation.getMetadataBag();
-    }
-
-    public void setMetadataBag(Map meMap) {
-        wsdloperation.setMetadataBag(meMap);
-    }
-
-
     /**
      * This method is responsible for finding a MEPContext for an incomming
      * messages. An incomming message can be of two states.
@@ -543,10 +404,6 @@
         }
     }
 
-    public void setWsdloperation(WSDLOperationImpl wsdloperation) {
-        this.wsdloperation = wsdloperation;
-    }
-
     public ArrayList getWsamappingList() {
         return wsamappingList;
     }
@@ -563,5 +420,12 @@
         this.controlOperation = controlOperation;
     }
 
+    public String getStyle() {
+        return style;
+    }
+
+    public void setStyle(String style) {
+        this.style = style;
+    }
 
 }

Modified: webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/description/AxisService.java
URL: http://svn.apache.org/viewcvs/webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/description/AxisService.java?rev=356539&r1=356538&r2=356539&view=diff
==============================================================================
--- webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/description/AxisService.java (original)
+++ webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/description/AxisService.java Tue Dec 13 08:50:12 2005
@@ -23,17 +23,6 @@
 import org.apache.axis2.om.OMElement;
 import org.apache.commons.logging.Log;
 import org.apache.commons.logging.LogFactory;
-import org.apache.wsdl.WSDLBindingOperation;
-import org.apache.wsdl.WSDLEndpoint;
-import org.apache.wsdl.WSDLExtensibilityAttribute;
-import org.apache.wsdl.WSDLExtensibilityElement;
-import org.apache.wsdl.WSDLInterface;
-import org.apache.wsdl.WSDLOperation;
-import org.apache.wsdl.WSDLService;
-import org.apache.wsdl.extensions.ExtensionConstants;
-import org.apache.wsdl.extensions.SOAPOperation;
-import org.apache.wsdl.impl.WSDLInterfaceImpl;
-import org.apache.wsdl.impl.WSDLServiceImpl;
 
 import javax.wsdl.Definition;
 import javax.wsdl.Port;
@@ -44,21 +33,14 @@
 import javax.xml.namespace.QName;
 import java.io.IOException;
 import java.io.Writer;
-import java.util.ArrayList;
-import java.util.Collection;
-import java.util.Date;
-import java.util.HashMap;
-import java.util.Iterator;
-import java.util.List;
-import java.util.Map;
+import java.util.*;
 
 /**
  * Class AxisService
  */
 public class AxisService
 // extends WSDLServiceImpl
-        implements WSDLService, ParameterInclude, FlowInclude,
-        DescriptionConstants {
+        implements ParameterInclude, DescriptionConstants {
 
     private Definition definition = null;
 
@@ -77,7 +59,7 @@
 
     private String fileName = "";
 
-    private WSDLService serviceimpl = null;
+//    private WSDLService serviceimpl = null;
 
     private HashMap operationsAliasesMap = null;
 
@@ -89,35 +71,26 @@
     // to store engaged mdodules
     private ArrayList engagedModules = new ArrayList();
 
+    private ParameterInclude paramterInclude;
+    private String name;
+    private ClassLoader serviceClassLoader;
+
     /**
      * Constructor AxisService
      */
 
-    public AxisService(WSDLService serviceimpl) {
-        this.serviceimpl = serviceimpl;
-        this.operationsAliasesMap = new HashMap();
-        this.setComponentProperty(PARAMETER_KEY, new ParameterIncludeImpl());
-        this.setServiceInterface(new WSDLInterfaceImpl());
-        moduleConfigmap = new HashMap();
-
-    }
-
     public AxisService() {
-        this.serviceimpl = new WSDLServiceImpl();
+        this.paramterInclude = new ParameterIncludeImpl();
         this.operationsAliasesMap = new HashMap();
-        this.setComponentProperty(PARAMETER_KEY, new ParameterIncludeImpl());
-        this.setServiceInterface(new WSDLInterfaceImpl());
         moduleConfigmap = new HashMap();
     }
 
     /**
      * Constructor AxisService
-     *
-     * @param qName
      */
-    public AxisService(QName qName) {
+    public AxisService(String name) {
         this();
-        this.setName(qName);
+        this.name = name;
     }
 
     /*
@@ -132,7 +105,7 @@
      * @param moduleref
      */
     public void engageModule(ModuleDescription moduleref,
-            AxisConfiguration axisConfig) throws AxisFault {
+                             AxisConfiguration axisConfig) throws AxisFault {
         if (moduleref == null) {
             return;
         }
@@ -169,7 +142,7 @@
      */
 
     public void addModuleOperations(ModuleDescription module,
-            AxisConfiguration axisConfig) throws AxisFault {
+                                    AxisConfiguration axisConfig) throws AxisFault {
         HashMap map = module.getOperations();
         Collection col = map.values();
         for (Iterator iterator = col.iterator(); iterator.hasNext();) {
@@ -201,7 +174,6 @@
                         .getMessageExchangePattern());
         operation.setMessageReceiver(axisOperation.getMessageReceiver());
         operation.setName(axisOperation.getName());
-        operation.setStyle(axisOperation.getStyle());
         Iterator parameters = axisOperation.getParameters().iterator();
         while (parameters.hasNext()) {
             Parameter parameter = (Parameter) parameters.next();
@@ -239,23 +211,11 @@
         return axisOperation;
     }
 
-    /**
-     * To get the WSDL operation element in service interface
-     *
-     * @param operationName
-     *            <code>QName</cde>
-     * @return WSDLOperation <code>WSDLOperation</code>
-     */
-    public WSDLOperation getWSDLOPOperation(QName operationName) {
-        String opStr = operationName.getLocalPart();
-        return this.getServiceInterface().getOperation(opStr);
-    }
-
     /*
-     * (non-Javadoc)
-     *
-     * @see org.apache.axis2.description.AxisService#addOperation(org.apache.axis2.description.AxisOperation)
-     */
+    * (non-Javadoc)
+    *
+    * @see org.apache.axis2.description.AxisService#addOperation(org.apache.axis2.description.AxisOperation)
+    */
 
     /**
      * Method addOperation
@@ -296,7 +256,7 @@
      * @param classLoader
      */
     public void setClassLoader(ClassLoader classLoader) {
-        this.setComponentProperty(CLASSLOADER_KEY, classLoader);
+        this.serviceClassLoader = classLoader;
     }
 
     /*
@@ -311,86 +271,9 @@
      * @return ClassLoader
      */
     public ClassLoader getClassLoader() {
-        return (ClassLoader) this.getComponentProperty(CLASSLOADER_KEY);
-    }
-
-    /*
-     * (non-Javadoc)
-     *
-     * @see org.apache.axis2.description.AxisService#setContextPath(java.lang.String)
-     */
-
-    /**
-     * Method setContextPath
-     *
-     * @param contextPath
-     */
-    public void setContextPath(String contextPath) {
-        if (contextPath != null) {
-            this.setComponentProperty(CONTEXTPATH_KEY, contextPath);
-        }
-    }
-
-    /*
-     * (non-Javadoc)
-     *
-     * @see org.apache.axis2.description.AxisService#getContextPath()
-     */
-
-    /**
-     * Method getContextPath
-     *
-     * @return String
-     */
-    public String getContextPath() {
-        return (String) this.getComponentProperty(CONTEXTPATH_KEY);
-    }
-
-    /*
-     * (non-Javadoc)
-     *
-     * @see org.apache.axis2.description.AxisService#setStyle(javax.swing.text.Style)
-     */
-
-    /**
-     * Method setStyle
-     *
-     * @param style
-     */
-    public void setStyle(String style) {
-        if (style != null) {
-            this.setComponentProperty(STYLE_KEY, style);
-        }
+        return this.serviceClassLoader;
     }
 
-    /*
-     * (non-Javadoc)
-     *
-     * @see org.apache.axis2.description.AxisService#getStyle()
-     */
-
-    /**
-     * Method getStyle
-     *
-     * @return String
-     */
-    public String getStyle() {
-        return (String) this.getComponentProperty(STYLE_KEY);
-    }
-
-    /*
-     * (non-Javadoc)
-     *
-     * @see org.apache.axis2.description.PhasesInclude#getPhases(java.util.ArrayList,
-     *      int)
-     */
-
-    /*
-     * (non-Javadoc)
-     *
-     * @see org.apache.axis2.description.ParameterInclude#addParameter(org.apache.axis2.description.Parameter)
-     */
-
     /**
      * Method addParameter
      *
@@ -405,9 +288,7 @@
             throw new AxisFault("Parmter is locked can not overide: "
                     + param.getName());
         } else {
-            ParameterIncludeImpl paramInclude = (ParameterIncludeImpl) this
-                    .getComponentProperty(PARAMETER_KEY);
-            paramInclude.addParameter(param);
+            paramterInclude.addParameter(param);
         }
     }
 
@@ -424,121 +305,11 @@
      * @return Parameter
      */
     public Parameter getParameter(String name) {
-        ParameterIncludeImpl paramInclude = (ParameterIncludeImpl) this
-                .getComponentProperty(PARAMETER_KEY);
-        return paramInclude.getParameter(name);
+        return paramterInclude.getParameter(name);
     }
 
     public ArrayList getParameters() {
-        ParameterIncludeImpl paramInclude = (ParameterIncludeImpl) this
-                .getComponentProperty(PARAMETER_KEY);
-        return paramInclude.getParameters();
-    }
-
-    /*
-     * (non-Javadoc)
-     *
-     * @see org.apache.axis2.description.FlowInclude#getInFlow()
-     */
-
-    /**
-     * Method getInFlow
-     *
-     * @return Flow
-     */
-    public Flow getInFlow() {
-        return (Flow) this.getComponentProperty(INFLOW_KEY);
-    }
-
-    /*
-     * (non-Javadoc)
-     *
-     * @see org.apache.axis2.description.FlowInclude#setInFlow(org.apache.axis2.description.Flow)
-     */
-
-    /**
-     * Method setInFlow
-     *
-     * @param inFlow
-     */
-    public void setInFlow(Flow inFlow) {
-        if (inFlow != null) {
-            this.setComponentProperty(INFLOW_KEY, inFlow);
-        }
-    }
-
-    /*
-     * (non-Javadoc)
-     *
-     * @see org.apache.axis2.description.FlowInclude#getOutFlow()
-     */
-
-    /**
-     * Method getOutFlow
-     *
-     * @return Flow
-     */
-    public Flow getOutFlow() {
-        return (Flow) this.getComponentProperty(OUTFLOW_KEY);
-    }
-
-    /*
-     * (non-Javadoc)
-     *
-     * @see org.apache.axis2.description.FlowInclude#setOutFlow(org.apache.axis2.description.Flow)
-     */
-
-    /**
-     * Method setOutFlow
-     *
-     * @param outFlow
-     */
-    public void setOutFlow(Flow outFlow) {
-        if (outFlow != null) {
-            this.setComponentProperty(OUTFLOW_KEY, outFlow);
-        }
-    }
-
-    /*
-     * (non-Javadoc)
-     *
-     * @see org.apache.axis2.description.FlowInclude#getFaultInFlow()
-     */
-
-    /**
-     * Method getFaultInFlow
-     *
-     * @return Flow
-     */
-    public Flow getFaultInFlow() {
-        return (Flow) this.getComponentProperty(IN_FAULTFLOW_KEY);
-    }
-
-    /*
-     * (non-Javadoc)
-     *
-     * @see org.apache.axis2.description.FlowInclude#setFaultInFlow(org.apache.axis2.description.Flow)
-     */
-
-    /**
-     * Method setFaultInFlow
-     *
-     * @param faultFlow
-     */
-    public void setFaultInFlow(Flow faultFlow) {
-        if (faultFlow != null) {
-            this.setComponentProperty(IN_FAULTFLOW_KEY, faultFlow);
-        }
-    }
-
-    public Flow getFaultOutFlow() {
-        return (Flow) this.getComponentProperty(OUT_FAULTFLOW_KEY);
-    }
-
-    public void setFaultOutFlow(Flow faultFlow) {
-        if (faultFlow != null) {
-            this.setComponentProperty(OUT_FAULTFLOW_KEY, faultFlow);
-        }
+        return paramterInclude.getParameters();
     }
 
     /**
@@ -589,8 +360,7 @@
      * null will be ruturned. If no particular Operation is found with the given
      * SOAP Action; null will be returned.
      *
-     * @param soapAction
-     *            SOAP Action defined for the particular Operation
+     * @param soapAction SOAP Action defined for the particular Operation
      * @return A AxisOperation if a unque Operation can be found with the given
      *         SOAP Action otherwise will return null.
      */
@@ -598,67 +368,13 @@
         if (soapAction == null || soapAction.equals("")) {
             return null;
         }
-        Iterator iterator = this.getEndpoints().keySet().iterator();
-        if (iterator.hasNext()) {
-            WSDLEndpoint endpoint = (WSDLEndpoint) this.getEndpoints().get(
-                    iterator.next());
-            return this
-                    .getOperationBySOAPAction(soapAction, endpoint.getName());
-        }
-
-        return null;
-
-    }
-
-    /**
-     * This method will return the operation given the particular endpoing and
-     * the particular SOAP Action. If more than one Operation is found with the
-     * given SOAP Action; null will be ruturned. If no particular Operation is
-     * found with the given SOAP Action; null will be returned
-     *
-     * @param endpoint
-     *            Particular Enpoint in which the bining is defined with the
-     *            particular SOAP Action.
-     * @param soapAction
-     *            SOAP Action defined for the particular Operation
-     * @return A AxisOperation if a unque Operation can be found with the given
-     *         SOAP Action otherwise will return null.
-     */
-    public AxisOperation getOperationBySOAPAction(String soapAction,
-            QName endpoint) {
-        HashMap bindingOperations = this.getEndpoint(endpoint).getBinding()
-                .getBindingOperations();
-        Iterator operationKeySetIterator = bindingOperations.keySet()
-                .iterator();
-        AxisOperation axisOperation = null;
-        int count = 0;
-        while (operationKeySetIterator.hasNext()) {
-            WSDLBindingOperation bindingOperation = (WSDLBindingOperation) bindingOperations
-                    .get(operationKeySetIterator.next());
-            Iterator extIterator = bindingOperation.getExtensibilityElements()
-                    .iterator();
-            while (extIterator.hasNext()) {
-                WSDLExtensibilityElement element = (WSDLExtensibilityElement) extIterator
-                        .next();
-                if (ExtensionConstants.SOAP_11_OPERATION.equals(element
-                        .getType())
-                        || ExtensionConstants.SOAP_12_OPERATION.equals(element
-                                .getType())) {
-                    if (((SOAPOperation) element).getSoapAction().equals(
-                            soapAction)) {
-                        WSDLOperation op = bindingOperation.getOperation();
-                        if (op instanceof AxisOperation) {
-                            axisOperation = (AxisOperation) op;
-                            count++;
-                        }
-                    }
-                }
-            }
-        }
-        if (1 == count) {
-            return axisOperation;
+        AxisOperation operation = (AxisOperation) operations.get(new QName(soapAction));
+        if (operation != null) {
+            return operation;
         }
-        return null;
+        operation = (AxisOperation) operationsAliasesMap.get(soapAction);
+        return operation;
+        //todo do we need to improve thise ?
     }
 
     /**
@@ -700,7 +416,7 @@
                     for (Iterator iterator1 = ports.iterator(); iterator1
                             .hasNext();) {
                         Port port = (Port) iterator1.next();
-                        service.setQName(this.getName());
+                        service.setQName(new QName(this.getName()));
                         SOAPAddress soapAddress = new SOAPAddressImpl();
                         soapAddress
                                 .setElementType(SOAPConstants.Q_ELEM_SOAP_ADDRESS);
@@ -746,91 +462,13 @@
         this.fileName = fileName;
     }
 
-    public HashMap getEndpoints() {
-        return serviceimpl.getEndpoints();
-    }
-
-    public void setEndpoints(HashMap endpoints) {
-        serviceimpl.setEndpoints(endpoints);
-    }
-
-    public void setEndpoint(WSDLEndpoint endpoint) {
-        serviceimpl.setEndpoint(endpoint);
-    }
-
-    public WSDLEndpoint getEndpoint(QName qName) {
-        return serviceimpl.getEndpoint(qName);
-    }
-
-    public QName getName() {
-        return serviceimpl.getName();
-    }
-
-    public void setName(QName name) {
-        serviceimpl.setName(name);
-    }
-
-    public String getNamespace() {
-        return serviceimpl.getNamespace();
-    }
-
-    public WSDLInterface getServiceInterface() {
-        return serviceimpl.getServiceInterface();
-    }
-
-    public void setServiceInterface(WSDLInterface serviceInterface) {
-        serviceimpl.setServiceInterface(serviceInterface);
-    }
-
-    public HashMap getComponentProperties() {
-        return serviceimpl.getComponentProperties();
-    }
-
-    public void setComponentProperties(HashMap properties) {
-        serviceimpl.setComponentProperties(properties);
-    }
-
-    public void setComponentProperty(Object key, Object obj) {
-        serviceimpl.setComponentProperty(key, obj);
-    }
-
-    public Object getComponentProperty(Object key) {
-        return serviceimpl.getComponentProperty(key);
-    }
-
-    public void addExtensibilityElement(WSDLExtensibilityElement element) {
-        serviceimpl.addExtensibilityElement(element);
-    }
-
-    public List getExtensibilityElements() {
-        return serviceimpl.getExtensibilityElements();
-    }
-
-    public List getExtensibilityAttributes() {
-        return serviceimpl.getExtensibilityAttributes();
-    }
-
-    public void addExtensibleAttributes(WSDLExtensibilityAttribute attribute) {
-        serviceimpl.addExtensibleAttributes(attribute);
-    }
-
-    public Map getMetadataBag() {
-        return serviceimpl.getMetadataBag();
-    }
-
-    public void setMetadataBag(Map map) {
-        this.serviceimpl.setMetadataBag(map);
-    }
-
     /**
      * Map an action (ala WSA action) to the given operation. This is used by
      * addressing based dispatching to figure out which operation it is that a
      * given message is for.
      *
-     * @param action
-     *            the action key
-     * @param axisOperation
-     *            the operation to map to
+     * @param action        the action key
+     * @param axisOperation the operation to map to
      */
     public void mapActionToOperation(String action, AxisOperation axisOperation) {
         operationsAliasesMap.put(action, axisOperation);
@@ -839,8 +477,7 @@
     /**
      * Return the AxisOperation which has been mapped to the given action.
      *
-     * @param action
-     *            the action key
+     * @param action the action key
      * @return the corresponding AxisOperation or null if it isn't found
      */
     public AxisOperation getOperationByAction(String action) {
@@ -879,9 +516,7 @@
 
     public void deserializeParameters(OMElement parameterElement)
             throws AxisFault {
-        ParameterIncludeImpl paramInclude = (ParameterIncludeImpl) this
-                .getComponentProperty(PARAMETER_KEY);
-        paramInclude.deserializeParameters(parameterElement);
+        paramterInclude.deserializeParameters(parameterElement);
     }
 
     /**
@@ -904,6 +539,14 @@
 
     public ArrayList getModules() {
         return moduleRefs;
+    }
+
+    public String getName() {
+        return name;
+    }
+
+    public void setName(String name) {
+        this.name = name;
     }
 
 }

Modified: webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/description/InOnlyAxisOperation.java
URL: http://svn.apache.org/viewcvs/webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/description/InOnlyAxisOperation.java?rev=356539&r1=356538&r2=356539&view=diff
==============================================================================
--- webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/description/InOnlyAxisOperation.java (original)
+++ webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/description/InOnlyAxisOperation.java Tue Dec 13 08:50:12 2005
@@ -4,7 +4,6 @@
 import org.apache.axis2.context.MessageContext;
 import org.apache.axis2.context.OperationContext;
 import org.apache.wsdl.WSDLConstants;
-import org.apache.wsdl.WSDLOperation;
 
 import javax.xml.namespace.QName;
 import java.util.ArrayList;
@@ -39,11 +38,6 @@
 
     //this is just to stor the chain , there wont be any usage of this
     private ArrayList outPhase;
-
-    public InOnlyAxisOperation(WSDLOperation wsdloperation) {
-        super(wsdloperation);
-        createMessage();
-    }
 
     private void createMessage() {
         inMessage = new AxisMessage();

Modified: webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/description/InOutAxisOperation.java
URL: http://svn.apache.org/viewcvs/webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/description/InOutAxisOperation.java?rev=356539&r1=356538&r2=356539&view=diff
==============================================================================
--- webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/description/InOutAxisOperation.java (original)
+++ webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/description/InOutAxisOperation.java Tue Dec 13 08:50:12 2005
@@ -4,7 +4,6 @@
 import org.apache.axis2.context.MessageContext;
 import org.apache.axis2.context.OperationContext;
 import org.apache.wsdl.WSDLConstants;
-import org.apache.wsdl.WSDLOperation;
 
 import javax.xml.namespace.QName;
 import java.util.ArrayList;
@@ -34,22 +33,19 @@
  */
 public class InOutAxisOperation extends AxisOperation {
 
+
     private AxisMessage inMessage;
     private AxisMessage inFaultMessage;
     private AxisMessage outFaultMessage;
     private AxisMessage outMessage;
 
-    public InOutAxisOperation(WSDLOperation wsdloperation) {
-        super(wsdloperation);
-        createMessages();
-    }
-
     private void createMessages() {
         inMessage = new AxisMessage();
         inFaultMessage = new AxisMessage();
         outFaultMessage = new AxisMessage();
         outMessage = new AxisMessage();
     }
+
 
     public InOutAxisOperation() {
         super();

Modified: webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/description/OutInAxisOperation.java
URL: http://svn.apache.org/viewcvs/webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/description/OutInAxisOperation.java?rev=356539&r1=356538&r2=356539&view=diff
==============================================================================
--- webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/description/OutInAxisOperation.java (original)
+++ webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/description/OutInAxisOperation.java Tue Dec 13 08:50:12 2005
@@ -3,7 +3,6 @@
 import org.apache.axis2.AxisFault;
 import org.apache.axis2.context.MessageContext;
 import org.apache.axis2.context.OperationContext;
-import org.apache.wsdl.WSDLOperation;
 
 import javax.xml.namespace.QName;
 import java.util.HashMap;
@@ -32,16 +31,12 @@
  */
 public class OutInAxisOperation extends InOutAxisOperation {
 
-    public OutInAxisOperation(WSDLOperation wsdloperation) {
-        super(wsdloperation);
+    public OutInAxisOperation(QName name) {
+        super(name);
     }
 
     public OutInAxisOperation() {
-        super();
-    }
-
-    public OutInAxisOperation(QName name) {
-        super(name);
+        super();   
     }
 
     public void addMessageContext(MessageContext msgContext, OperationContext opContext) throws AxisFault {

Modified: webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/description/OutOnlyAxisOperation.java
URL: http://svn.apache.org/viewcvs/webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/description/OutOnlyAxisOperation.java?rev=356539&r1=356538&r2=356539&view=diff
==============================================================================
--- webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/description/OutOnlyAxisOperation.java (original)
+++ webservices/axis2/trunk/java/modules/core/src/org/apache/axis2/description/OutOnlyAxisOperation.java Tue Dec 13 08:50:12 2005
@@ -33,12 +33,7 @@
 
     //just to keep the inflow , there wont be any usage
     private ArrayList inPhases;
-
-    public OutOnlyAxisOperation(WSDLOperation wsdloperation) {
-        super(wsdloperation);
-        createMessage();
-    }
-
+   
     private void createMessage() {
         outMessage = new AxisMessage();
         inFaultMessage = new AxisMessage();