You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@tuscany.apache.org by lr...@apache.org on 2007/09/08 01:20:28 UTC

svn commit: r573753 - in /incubator/tuscany/java/sca/modules/implementation-bpel/src: main/java/org/apache/tuscany/sca/implementation/bpel/ main/java/org/apache/tuscany/sca/implementation/bpel/impl/ main/java/org/apache/tuscany/sca/implementation/bpel/...

Author: lresende
Date: Fri Sep  7 16:20:24 2007
New Revision: 573753

URL: http://svn.apache.org/viewvc?rev=573753&view=rev
Log:
Code refactoring/cleanup and adding couple test cases for BPEL implementation

Added:
    incubator/tuscany/java/sca/modules/implementation-bpel/src/main/java/org/apache/tuscany/sca/implementation/bpel/BPELFactory.java
      - copied, changed from r573630, incubator/tuscany/java/sca/modules/implementation-bpel/src/main/java/org/apache/tuscany/sca/implementation/bpel/BPELImplementationFactory.java
    incubator/tuscany/java/sca/modules/implementation-bpel/src/main/java/org/apache/tuscany/sca/implementation/bpel/BPELProcessDefinition.java   (with props)
    incubator/tuscany/java/sca/modules/implementation-bpel/src/main/java/org/apache/tuscany/sca/implementation/bpel/DefaultBPELFactory.java
      - copied, changed from r573630, incubator/tuscany/java/sca/modules/implementation-bpel/src/main/java/org/apache/tuscany/sca/implementation/bpel/DefaultBPELImplementationFactory.java
    incubator/tuscany/java/sca/modules/implementation-bpel/src/main/java/org/apache/tuscany/sca/implementation/bpel/impl/BPELDocumentProcessor.java
      - copied, changed from r573432, incubator/tuscany/java/sca/modules/implementation-bpel/src/main/java/org/apache/tuscany/sca/implementation/bpel/impl/BPELArtifactProcessor.java
    incubator/tuscany/java/sca/modules/implementation-bpel/src/main/java/org/apache/tuscany/sca/implementation/bpel/impl/BPELImplementationProcessor.java
      - copied, changed from r573163, incubator/tuscany/java/sca/modules/implementation-bpel/src/main/java/org/apache/tuscany/sca/implementation/bpel/impl/BPELArtifactProcessor.java
    incubator/tuscany/java/sca/modules/implementation-bpel/src/main/java/org/apache/tuscany/sca/implementation/bpel/impl/BPELProcessDefinitionImpl.java   (with props)
    incubator/tuscany/java/sca/modules/implementation-bpel/src/test/java/org/apache/tuscany/sca/implementation/bpel/BPELDocumentProcessorTestCase.java   (with props)
    incubator/tuscany/java/sca/modules/implementation-bpel/src/test/java/org/apache/tuscany/sca/implementation/bpel/BPELImplementationProcessorTestCase.java   (with props)
Removed:
    incubator/tuscany/java/sca/modules/implementation-bpel/src/main/java/org/apache/tuscany/sca/implementation/bpel/BPEL.java
    incubator/tuscany/java/sca/modules/implementation-bpel/src/main/java/org/apache/tuscany/sca/implementation/bpel/BPELImplementationFactory.java
    incubator/tuscany/java/sca/modules/implementation-bpel/src/main/java/org/apache/tuscany/sca/implementation/bpel/DefaultBPELImplementationFactory.java
    incubator/tuscany/java/sca/modules/implementation-bpel/src/main/java/org/apache/tuscany/sca/implementation/bpel/impl/BPELArtifactProcessor.java
Modified:
    incubator/tuscany/java/sca/modules/implementation-bpel/src/main/java/org/apache/tuscany/sca/implementation/bpel/BPELImplementation.java
    incubator/tuscany/java/sca/modules/implementation-bpel/src/main/java/org/apache/tuscany/sca/implementation/bpel/impl/BPELImplementationImpl.java
    incubator/tuscany/java/sca/modules/implementation-bpel/src/main/java/org/apache/tuscany/sca/implementation/bpel/provider/BPELImplementationProvider.java
    incubator/tuscany/java/sca/modules/implementation-bpel/src/main/resources/META-INF/services/org.apache.tuscany.sca.contribution.processor.StAXArtifactProcessor
    incubator/tuscany/java/sca/modules/implementation-bpel/src/test/java/org/apache/tuscany/sca/implementation/bpel/BPELTestCase.java
    incubator/tuscany/java/sca/modules/implementation-bpel/src/test/resources/helloworld.composite

Copied: incubator/tuscany/java/sca/modules/implementation-bpel/src/main/java/org/apache/tuscany/sca/implementation/bpel/BPELFactory.java (from r573630, incubator/tuscany/java/sca/modules/implementation-bpel/src/main/java/org/apache/tuscany/sca/implementation/bpel/BPELImplementationFactory.java)
URL: http://svn.apache.org/viewvc/incubator/tuscany/java/sca/modules/implementation-bpel/src/main/java/org/apache/tuscany/sca/implementation/bpel/BPELFactory.java?p2=incubator/tuscany/java/sca/modules/implementation-bpel/src/main/java/org/apache/tuscany/sca/implementation/bpel/BPELFactory.java&p1=incubator/tuscany/java/sca/modules/implementation-bpel/src/main/java/org/apache/tuscany/sca/implementation/bpel/BPELImplementationFactory.java&r1=573630&r2=573753&rev=573753&view=diff
==============================================================================
--- incubator/tuscany/java/sca/modules/implementation-bpel/src/main/java/org/apache/tuscany/sca/implementation/bpel/BPELImplementationFactory.java (original)
+++ incubator/tuscany/java/sca/modules/implementation-bpel/src/main/java/org/apache/tuscany/sca/implementation/bpel/BPELFactory.java Fri Sep  7 16:20:24 2007
@@ -24,13 +24,18 @@
  * 
  * @version $Rev$ $Date$
  */
-public interface BPELImplementationFactory {
+public interface BPELFactory {
     
     /**
-     * Creates a new CRUD implementation.
+     * Creates a new BPEL implementation.
      * 
      * @return
      */
     BPELImplementation createBPELImplementation();
 
+    /**
+     * Creates a new BPEL Process Definition
+     * @return
+     */
+    BPELProcessDefinition createBPELProcessDefinition();
 }

Modified: incubator/tuscany/java/sca/modules/implementation-bpel/src/main/java/org/apache/tuscany/sca/implementation/bpel/BPELImplementation.java
URL: http://svn.apache.org/viewvc/incubator/tuscany/java/sca/modules/implementation-bpel/src/main/java/org/apache/tuscany/sca/implementation/bpel/BPELImplementation.java?rev=573753&r1=573752&r2=573753&view=diff
==============================================================================
--- incubator/tuscany/java/sca/modules/implementation-bpel/src/main/java/org/apache/tuscany/sca/implementation/bpel/BPELImplementation.java (original)
+++ incubator/tuscany/java/sca/modules/implementation-bpel/src/main/java/org/apache/tuscany/sca/implementation/bpel/BPELImplementation.java Fri Sep  7 16:20:24 2007
@@ -18,34 +18,38 @@
  */
 package org.apache.tuscany.sca.implementation.bpel;
 
-import org.apache.tuscany.sca.assembly.Extensible;
-import org.apache.tuscany.sca.assembly.Implementation;
-import org.apache.ode.bpel.iapi.ProcessConf;
-
 import javax.xml.namespace.QName;
 
+import org.apache.tuscany.sca.assembly.Implementation;
+
 /**
  * The model representing the BPEL implementation in an SCA assembly model.
  * 
  * @version $Rev$ $Date$
  */
-public interface BPELImplementation extends Implementation, Extensible {
+public interface BPELImplementation extends Implementation {
 
     /**
      * Builds the process configuration used by ODE to get deployment and configuration
      * level information about a process.
      * @return
      */
-    ProcessConf getProcessConf();
+    //ProcessConf getProcessConf();
 
     /**
      * Sets the implementation compiled process bytes
      * @param compiledProcess serialized compiled process
      */
-    void setCompiledProcess(byte[] compiledProcess);
+    //void setCompiledProcess(byte[] compiledProcess);
 
     /**
+     * Get the BPEL process Name
+     */
+    QName getProcess();
+    
+    /**
+     * Set the BPEL process Name
      * @param processName process QName
      */
-    void setProcessName(QName processName);
+    void setProcess(QName processName);
 }

Added: incubator/tuscany/java/sca/modules/implementation-bpel/src/main/java/org/apache/tuscany/sca/implementation/bpel/BPELProcessDefinition.java
URL: http://svn.apache.org/viewvc/incubator/tuscany/java/sca/modules/implementation-bpel/src/main/java/org/apache/tuscany/sca/implementation/bpel/BPELProcessDefinition.java?rev=573753&view=auto
==============================================================================
--- incubator/tuscany/java/sca/modules/implementation-bpel/src/main/java/org/apache/tuscany/sca/implementation/bpel/BPELProcessDefinition.java (added)
+++ incubator/tuscany/java/sca/modules/implementation-bpel/src/main/java/org/apache/tuscany/sca/implementation/bpel/BPELProcessDefinition.java Fri Sep  7 16:20:24 2007
@@ -0,0 +1,58 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ * 
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ * 
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.    
+ */
+
+package org.apache.tuscany.sca.implementation.bpel;
+
+import java.net.URL;
+
+import javax.xml.namespace.QName;
+
+import org.apache.tuscany.sca.assembly.Base;
+
+
+/**
+ * The BPEL process definition.
+ * 
+ * @version $Rev$ $Date$
+ */
+public interface BPELProcessDefinition extends Base {
+    
+    /**
+     * Get the BPEL process Name
+     */
+    public QName getName();
+    
+    /**
+     * Set the BPEL process Name
+     * @param processName process QName
+     */
+    public void setName(QName name);
+    
+    /**
+     * Get the URI for the process location
+     * @return
+     */
+    URL getLocation();
+    
+    /**
+     * Set the URI for the process location
+     * @param url
+     */
+    void setLocation(URL location);
+}

Propchange: incubator/tuscany/java/sca/modules/implementation-bpel/src/main/java/org/apache/tuscany/sca/implementation/bpel/BPELProcessDefinition.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/tuscany/java/sca/modules/implementation-bpel/src/main/java/org/apache/tuscany/sca/implementation/bpel/BPELProcessDefinition.java
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Copied: incubator/tuscany/java/sca/modules/implementation-bpel/src/main/java/org/apache/tuscany/sca/implementation/bpel/DefaultBPELFactory.java (from r573630, incubator/tuscany/java/sca/modules/implementation-bpel/src/main/java/org/apache/tuscany/sca/implementation/bpel/DefaultBPELImplementationFactory.java)
URL: http://svn.apache.org/viewvc/incubator/tuscany/java/sca/modules/implementation-bpel/src/main/java/org/apache/tuscany/sca/implementation/bpel/DefaultBPELFactory.java?p2=incubator/tuscany/java/sca/modules/implementation-bpel/src/main/java/org/apache/tuscany/sca/implementation/bpel/DefaultBPELFactory.java&p1=incubator/tuscany/java/sca/modules/implementation-bpel/src/main/java/org/apache/tuscany/sca/implementation/bpel/DefaultBPELImplementationFactory.java&r1=573630&r2=573753&rev=573753&view=diff
==============================================================================
--- incubator/tuscany/java/sca/modules/implementation-bpel/src/main/java/org/apache/tuscany/sca/implementation/bpel/DefaultBPELImplementationFactory.java (original)
+++ incubator/tuscany/java/sca/modules/implementation-bpel/src/main/java/org/apache/tuscany/sca/implementation/bpel/DefaultBPELFactory.java Fri Sep  7 16:20:24 2007
@@ -21,6 +21,7 @@
 
 import org.apache.tuscany.sca.assembly.AssemblyFactory;
 import org.apache.tuscany.sca.implementation.bpel.impl.BPELImplementationImpl;
+import org.apache.tuscany.sca.implementation.bpel.impl.BPELProcessDefinitionImpl;
 import org.apache.tuscany.sca.interfacedef.wsdl.WSDLFactory;
 
 /**
@@ -28,12 +29,12 @@
  * 
  * @version $Rev$ $Date$
  */
-public class DefaultBPELImplementationFactory implements BPELImplementationFactory {
+public class DefaultBPELFactory implements BPELFactory {
     
     private AssemblyFactory assemblyFactory;
     private WSDLFactory wsdlFactory;
     
-    public DefaultBPELImplementationFactory(AssemblyFactory assemblyFactory,
+    public DefaultBPELFactory(AssemblyFactory assemblyFactory,
                                             WSDLFactory wsdlFactory) {
         this.assemblyFactory = assemblyFactory;
         this.wsdlFactory = wsdlFactory;
@@ -42,5 +43,11 @@
     public BPELImplementation createBPELImplementation() {
         return new BPELImplementationImpl(assemblyFactory, wsdlFactory);
     }
+
+    public BPELProcessDefinition createBPELProcessDefinition() {
+        return new BPELProcessDefinitionImpl();
+    }
+    
+    
 
 }

Copied: incubator/tuscany/java/sca/modules/implementation-bpel/src/main/java/org/apache/tuscany/sca/implementation/bpel/impl/BPELDocumentProcessor.java (from r573432, incubator/tuscany/java/sca/modules/implementation-bpel/src/main/java/org/apache/tuscany/sca/implementation/bpel/impl/BPELArtifactProcessor.java)
URL: http://svn.apache.org/viewvc/incubator/tuscany/java/sca/modules/implementation-bpel/src/main/java/org/apache/tuscany/sca/implementation/bpel/impl/BPELDocumentProcessor.java?p2=incubator/tuscany/java/sca/modules/implementation-bpel/src/main/java/org/apache/tuscany/sca/implementation/bpel/impl/BPELDocumentProcessor.java&p1=incubator/tuscany/java/sca/modules/implementation-bpel/src/main/java/org/apache/tuscany/sca/implementation/bpel/impl/BPELArtifactProcessor.java&r1=573432&r2=573753&rev=573753&view=diff
==============================================================================
--- incubator/tuscany/java/sca/modules/implementation-bpel/src/main/java/org/apache/tuscany/sca/implementation/bpel/impl/BPELArtifactProcessor.java (original)
+++ incubator/tuscany/java/sca/modules/implementation-bpel/src/main/java/org/apache/tuscany/sca/implementation/bpel/impl/BPELDocumentProcessor.java Fri Sep  7 16:20:24 2007
@@ -16,127 +16,96 @@
  * specific language governing permissions and limitations
  * under the License.    
  */
-package org.apache.tuscany.sca.implementation.bpel.impl;
 
-import static javax.xml.stream.XMLStreamConstants.END_ELEMENT;
+package org.apache.tuscany.sca.implementation.bpel.impl;
 
-import java.io.ByteArrayOutputStream;
-import java.io.File;
 import java.io.IOException;
+import java.io.InputStream;
+import java.net.URI;
 import java.net.URL;
 
 import javax.xml.namespace.QName;
+import javax.xml.stream.XMLInputFactory;
+import javax.xml.stream.XMLStreamConstants;
 import javax.xml.stream.XMLStreamException;
 import javax.xml.stream.XMLStreamReader;
-import javax.xml.stream.XMLStreamWriter;
 
-import org.apache.ode.bpel.compiler.BpelC;
-import org.apache.tuscany.sca.assembly.AssemblyFactory;
-import org.apache.tuscany.sca.assembly.xml.Constants;
 import org.apache.tuscany.sca.contribution.ModelFactoryExtensionPoint;
-import org.apache.tuscany.sca.contribution.processor.StAXArtifactProcessor;
+import org.apache.tuscany.sca.contribution.processor.URLArtifactProcessor;
 import org.apache.tuscany.sca.contribution.resolver.ModelResolver;
 import org.apache.tuscany.sca.contribution.service.ContributionReadException;
 import org.apache.tuscany.sca.contribution.service.ContributionResolveException;
-import org.apache.tuscany.sca.contribution.service.ContributionWriteException;
-import org.apache.tuscany.sca.implementation.bpel.BPELImplementation;
-import org.apache.tuscany.sca.implementation.bpel.BPELImplementationFactory;
-import org.apache.tuscany.sca.implementation.bpel.DefaultBPELImplementationFactory;
-import org.apache.tuscany.sca.interfacedef.wsdl.WSDLFactory;
-
-/**
- * Implements a STAX artifact processor for BPEL implementations.
- * 
- * The artifact processor is responsible for processing <implementation.bpel>
- * elements in SCA assembly XML composite files and populating the BPEL
- * implementation model, resolving its references to other artifacts in the SCA
- * contribution, and optionally write the model back to SCA assembly XML.
- * 
- *  @version $Rev$ $Date$
- */
-public class BPELArtifactProcessor implements StAXArtifactProcessor<BPELImplementation> {
-    private static final QName IMPLEMENTATION_BPEL = new QName(Constants.SCA10_TUSCANY_NS, "implementation.bpel");
-    
-    private BPELImplementationFactory bpelFactory;
-    
-    public BPELArtifactProcessor(ModelFactoryExtensionPoint modelFactories) {
-        AssemblyFactory assemblyFactory = modelFactories.getFactory(AssemblyFactory.class);
-        WSDLFactory wsdlFactory = modelFactories.getFactory(WSDLFactory.class);
-        this.bpelFactory = new DefaultBPELImplementationFactory(assemblyFactory, wsdlFactory);
-    }
+import org.apache.tuscany.sca.implementation.bpel.BPELFactory;
+import org.apache.tuscany.sca.implementation.bpel.BPELProcessDefinition;
 
-    public QName getArtifactType() {
-        // Returns the qname of the XML element processed by this processor
-        return IMPLEMENTATION_BPEL;
+public class BPELDocumentProcessor implements URLArtifactProcessor<BPELProcessDefinition> {
+    public final static QName BPEL_PROCESS_DEFINITION = new QName("http://schemas.xmlsoap.org/ws/2004/03/business-process/", "process");
+    
+    private final static XMLInputFactory inputFactory = XMLInputFactory.newInstance();
+    
+    private final BPELFactory factory;
+    
+    public BPELDocumentProcessor(ModelFactoryExtensionPoint modelFactories) {
+        this.factory = modelFactories.getFactory(BPELFactory.class);
     }
+    
+    public String getArtifactType() {
+        return "*.wsdl";
+    }    
 
-    public Class<BPELImplementation> getModelType() {
-        // Returns the type of model processed by this processor
-        return BPELImplementation.class;
+    public Class<BPELProcessDefinition> getModelType() {
+        return BPELProcessDefinition.class;
     }
 
-    public BPELImplementation read(XMLStreamReader reader) throws ContributionReadException, XMLStreamException {
-        assert IMPLEMENTATION_BPEL.equals(reader.getName());
-        
-        // Read an <implementation.bpel> element
-
-        // Read the process attribute. 
-        QName process = getAttributeValueNS(reader, "process");
-        String bpelFile = reader.getAttributeValue(null, "file");
-
-        // Resolving the BPEL file and compiling it
-        URL bpelURL = getClass().getClassLoader().getResource(bpelFile);
-        if (bpelURL == null)
-            throw new ODEProcessException("Couldn't find referenced bpel file " + bpelFile);
-        BpelC bpelc = BpelC.newBpelCompiler();
-        ByteArrayOutputStream compiledProcess = new ByteArrayOutputStream();
-        bpelc.setOutputStream(compiledProcess);
+    public BPELProcessDefinition read(URL contributionURL, URI artifactURI, URL artifactURL) throws ContributionReadException {
         try {
-            bpelc.compile(new File(bpelURL.getFile()));
-        } catch (IOException e) {
-            e.printStackTrace();
-        }
-
-        // Create an initialize the BPEL implementation model
-        BPELImplementation implementation = bpelFactory.createBPELImplementation();
-        implementation.setProcessName(process);
-        implementation.setCompiledProcess(compiledProcess.toByteArray());
-        implementation.setUnresolved(false);
-        
-        // Skip to end element
-        while (reader.hasNext()) {
-            if (reader.next() == END_ELEMENT && IMPLEMENTATION_BPEL.equals(reader.getName())) {
-                break;
-            }
+            return indexRead(artifactURL);
+        } catch (Exception e) {
+            throw new ContributionReadException(e);
         }
-        
-        return implementation;
     }
 
-    public void resolve(BPELImplementation impl, ModelResolver resolver) throws ContributionResolveException {
-        System.out.println("IN RESOLVE");
-        if( impl != null && impl.isUnresolved()) {
-            
-            impl.setUnresolved(false);
-        }
-        
-    }
 
-    public void write(BPELImplementation model, XMLStreamWriter outputSource) throws ContributionWriteException {
-        //FIXME Implement
+    public void resolve(BPELProcessDefinition model, ModelResolver resolver) throws ContributionResolveException {
+        // TODO Auto-generated method stub
+
     }
+    
+    /**
+     * Read the namespace for the WSDL definition and inline schemas
+     * 
+     * @param doc
+     * @return
+     * @throws IOException
+     * @throws XMLStreamException
+     */
+    protected BPELProcessDefinition indexRead(URL doc) throws Exception {
+        BPELProcessDefinition processDefinition = factory.createBPELProcessDefinition();
+        processDefinition.setUnresolved(true);
+        processDefinition.setLocation(doc);
 
-    private QName getAttributeValueNS(XMLStreamReader reader, String attribute) {
-        String fullValue = reader.getAttributeValue(null, "process");
-        if (fullValue.indexOf(":") < 0)
-            throw new ODEProcessException("Attribute " + attribute + " with value " + fullValue +
-                    " in your composite should be prefixed (process=\"prefix:name\").");
-        String prefix = fullValue.substring(0, fullValue.indexOf(":"));
-        String name = fullValue.substring(fullValue.indexOf(":") + 1);
-        String nsUri = reader.getNamespaceContext().getNamespaceURI(prefix);
-        if (nsUri == null)
-            throw new ODEProcessException("Attribute " + attribute + " with value " + fullValue +
-                    " in your composite has un unrecognized namespace prefix.");
-        return new QName(nsUri, name, prefix);
+        InputStream is = doc.openStream();
+        try {
+            XMLStreamReader reader = inputFactory.createXMLStreamReader(is);
+            int eventType = reader.getEventType();
+            while (true) {
+                if (eventType == XMLStreamConstants.START_ELEMENT) {
+                    QName elementName = reader.getName();
+                    if (BPEL_PROCESS_DEFINITION.equals(elementName)) {
+                        processDefinition.setName(elementName);
+                    }
+                }
+                if (reader.hasNext()) {
+                    eventType = reader.next();
+                } else {
+                    break;
+                }
+            }
+            return processDefinition;
+        } finally {
+            is.close();
+        }
     }
+    
+
 }

Modified: incubator/tuscany/java/sca/modules/implementation-bpel/src/main/java/org/apache/tuscany/sca/implementation/bpel/impl/BPELImplementationImpl.java
URL: http://svn.apache.org/viewvc/incubator/tuscany/java/sca/modules/implementation-bpel/src/main/java/org/apache/tuscany/sca/implementation/bpel/impl/BPELImplementationImpl.java?rev=573753&r1=573752&r2=573753&view=diff
==============================================================================
--- incubator/tuscany/java/sca/modules/implementation-bpel/src/main/java/org/apache/tuscany/sca/implementation/bpel/impl/BPELImplementationImpl.java (original)
+++ incubator/tuscany/java/sca/modules/implementation-bpel/src/main/java/org/apache/tuscany/sca/implementation/bpel/impl/BPELImplementationImpl.java Fri Sep  7 16:20:24 2007
@@ -22,7 +22,6 @@
 import java.io.File;
 import java.io.InputStream;
 import java.net.URL;
-import java.util.ArrayList;
 import java.util.Collections;
 import java.util.Date;
 import java.util.List;
@@ -42,9 +41,6 @@
 import org.apache.tuscany.sca.assembly.Service;
 import org.apache.tuscany.sca.implementation.bpel.BPELImplementation;
 import org.apache.tuscany.sca.interfacedef.wsdl.WSDLFactory;
-import org.apache.tuscany.sca.policy.Intent;
-import org.apache.tuscany.sca.policy.IntentAttachPointType;
-import org.apache.tuscany.sca.policy.PolicySet;
 import org.w3c.dom.Node;
 
 /**
@@ -67,22 +63,17 @@
 
         _bpelService = assemblyFactory.createService();
         _bpelService.setName("BPEL");
-//        WSDLInterface wsdlInterface;
-//        try {
-//            wsdlInterface = introspector.introspect(BPEL.class);
-//        } catch (InvalidInterfaceException e) {
-//            throw new IllegalArgumentException(e);
-//        }
-//        WSDLInterfaceContract interfaceContract = wsdlFactory.createWSDLInterfaceContract();
-//        interfaceContract.setInterface(wsdlInterface);
-//        _bpelService.setInterfaceContract(interfaceContract);
     }
 
     public void setCompiledProcess(byte[] compiledProcess) {
         _compiledProcess = compiledProcess;
     }
 
-    public void setProcessName(QName processName) {
+    public QName getProcess() {
+        return _processName;
+    }
+    
+    public void setProcess(QName processName) {
         _processName = processName;
     }
 
@@ -124,12 +115,7 @@
     }
 
     
-    public List<Object> getExtensions() {
-        // The sample BPEL implementation does not support extensions
-        return Collections.emptyList();
-    }
-
-    public boolean isUnresolved() {
+       public boolean isUnresolved() {
         return this.unresolved;
     }
 

Copied: incubator/tuscany/java/sca/modules/implementation-bpel/src/main/java/org/apache/tuscany/sca/implementation/bpel/impl/BPELImplementationProcessor.java (from r573163, incubator/tuscany/java/sca/modules/implementation-bpel/src/main/java/org/apache/tuscany/sca/implementation/bpel/impl/BPELArtifactProcessor.java)
URL: http://svn.apache.org/viewvc/incubator/tuscany/java/sca/modules/implementation-bpel/src/main/java/org/apache/tuscany/sca/implementation/bpel/impl/BPELImplementationProcessor.java?p2=incubator/tuscany/java/sca/modules/implementation-bpel/src/main/java/org/apache/tuscany/sca/implementation/bpel/impl/BPELImplementationProcessor.java&p1=incubator/tuscany/java/sca/modules/implementation-bpel/src/main/java/org/apache/tuscany/sca/implementation/bpel/impl/BPELArtifactProcessor.java&r1=573163&r2=573753&rev=573753&view=diff
==============================================================================
--- incubator/tuscany/java/sca/modules/implementation-bpel/src/main/java/org/apache/tuscany/sca/implementation/bpel/impl/BPELArtifactProcessor.java (original)
+++ incubator/tuscany/java/sca/modules/implementation-bpel/src/main/java/org/apache/tuscany/sca/implementation/bpel/impl/BPELImplementationProcessor.java Fri Sep  7 16:20:24 2007
@@ -40,8 +40,8 @@
 import org.apache.tuscany.sca.contribution.service.ContributionResolveException;
 import org.apache.tuscany.sca.contribution.service.ContributionWriteException;
 import org.apache.tuscany.sca.implementation.bpel.BPELImplementation;
-import org.apache.tuscany.sca.implementation.bpel.BPELImplementationFactory;
-import org.apache.tuscany.sca.implementation.bpel.DefaultBPELImplementationFactory;
+import org.apache.tuscany.sca.implementation.bpel.BPELFactory;
+import org.apache.tuscany.sca.implementation.bpel.DefaultBPELFactory;
 import org.apache.tuscany.sca.interfacedef.wsdl.WSDLFactory;
 
 /**
@@ -54,15 +54,15 @@
  * 
  *  @version $Rev$ $Date$
  */
-public class BPELArtifactProcessor implements StAXArtifactProcessor<BPELImplementation> {
-    private static final QName IMPLEMENTATION_BPEL = new QName(Constants.SCA10_TUSCANY_NS, "implementation.bpel");
+public class BPELImplementationProcessor implements StAXArtifactProcessor<BPELImplementation> {
+    private static final QName IMPLEMENTATION_BPEL = new QName(Constants.SCA10_NS, "implementation.bpel");
     
-    private BPELImplementationFactory bpelFactory;
+    private BPELFactory bpelFactory;
     
-    public BPELArtifactProcessor(ModelFactoryExtensionPoint modelFactories) {
+    public BPELImplementationProcessor(ModelFactoryExtensionPoint modelFactories) {
         AssemblyFactory assemblyFactory = modelFactories.getFactory(AssemblyFactory.class);
         WSDLFactory wsdlFactory = modelFactories.getFactory(WSDLFactory.class);
-        this.bpelFactory = new DefaultBPELImplementationFactory(assemblyFactory, wsdlFactory);
+        this.bpelFactory = new DefaultBPELFactory(assemblyFactory, wsdlFactory);
     }
 
     public QName getArtifactType() {
@@ -82,26 +82,14 @@
 
         // Read the process attribute. 
         QName process = getAttributeValueNS(reader, "process");
-        String bpelFile = reader.getAttributeValue(null, "file");
 
-        // Resolving the BPEL file and compiling it
-        URL bpelURL = getClass().getClassLoader().getResource(bpelFile);
-        if (bpelURL == null)
-            throw new ODEProcessException("Couldn't find referenced bpel file " + bpelFile);
-        BpelC bpelc = BpelC.newBpelCompiler();
-        ByteArrayOutputStream compiledProcess = new ByteArrayOutputStream();
-        bpelc.setOutputStream(compiledProcess);
-        try {
-            bpelc.compile(new File(bpelURL.getFile()));
-        } catch (IOException e) {
-            e.printStackTrace();
-        }
 
         // Create an initialize the BPEL implementation model
         BPELImplementation implementation = bpelFactory.createBPELImplementation();
-        implementation.setProcessName(process);
-        implementation.setCompiledProcess(compiledProcess.toByteArray());
-        implementation.setUnresolved(false);
+        implementation.setProcess(process);
+        //FIXME:lresende
+        //implementation.setCompiledProcess(compiledProcess.toByteArray());
+        //implementation.setUnresolved(false);
         
         // Skip to end element
         while (reader.hasNext()) {

Added: incubator/tuscany/java/sca/modules/implementation-bpel/src/main/java/org/apache/tuscany/sca/implementation/bpel/impl/BPELProcessDefinitionImpl.java
URL: http://svn.apache.org/viewvc/incubator/tuscany/java/sca/modules/implementation-bpel/src/main/java/org/apache/tuscany/sca/implementation/bpel/impl/BPELProcessDefinitionImpl.java?rev=573753&view=auto
==============================================================================
--- incubator/tuscany/java/sca/modules/implementation-bpel/src/main/java/org/apache/tuscany/sca/implementation/bpel/impl/BPELProcessDefinitionImpl.java (added)
+++ incubator/tuscany/java/sca/modules/implementation-bpel/src/main/java/org/apache/tuscany/sca/implementation/bpel/impl/BPELProcessDefinitionImpl.java Fri Sep  7 16:20:24 2007
@@ -0,0 +1,80 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ * 
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ * 
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.    
+ */
+
+package org.apache.tuscany.sca.implementation.bpel.impl;
+
+import java.net.URL;
+
+import javax.xml.namespace.QName;
+
+import org.apache.tuscany.sca.implementation.bpel.BPELProcessDefinition;
+
+/**
+ * The BPEL process definition implementation.
+ * 
+ * @version $Rev$ $Date$
+ */
+public class BPELProcessDefinitionImpl implements BPELProcessDefinition {
+    private QName   name;
+    private URL     location;
+    private boolean unresolved;
+    
+    public QName getName() {
+        return name;
+    }
+
+    public void setName(QName name) {
+        this.name = name;
+    }
+
+    public URL getLocation() {
+        return this.location;
+    }
+
+    public void setLocation(URL location) {
+        this.location = location; 
+    }
+
+    public boolean isUnresolved() {
+        return unresolved;
+    }
+
+    public void setUnresolved(boolean undefined) {
+        this.unresolved = undefined;
+    }   
+    
+    public void compile() {
+        /*
+        String bpelFile = reader.getAttributeValue(null, "file");  // FIXME: 
+
+        // Resolving the BPEL file and compiling it
+        URL bpelURL = getClass().getClassLoader().getResource(bpelFile);
+        if (bpelURL == null)
+            throw new ODEProcessException("Couldn't find referenced bpel file " + bpelFile);
+        BpelC bpelc = BpelC.newBpelCompiler();
+        ByteArrayOutputStream compiledProcess = new ByteArrayOutputStream();
+        bpelc.setOutputStream(compiledProcess);
+        try {
+            bpelc.compile(new File(bpelURL.getFile()));
+        } catch (IOException e) {
+            e.printStackTrace();
+        }
+        */
+    }
+}

Propchange: incubator/tuscany/java/sca/modules/implementation-bpel/src/main/java/org/apache/tuscany/sca/implementation/bpel/impl/BPELProcessDefinitionImpl.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/tuscany/java/sca/modules/implementation-bpel/src/main/java/org/apache/tuscany/sca/implementation/bpel/impl/BPELProcessDefinitionImpl.java
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Modified: incubator/tuscany/java/sca/modules/implementation-bpel/src/main/java/org/apache/tuscany/sca/implementation/bpel/provider/BPELImplementationProvider.java
URL: http://svn.apache.org/viewvc/incubator/tuscany/java/sca/modules/implementation-bpel/src/main/java/org/apache/tuscany/sca/implementation/bpel/provider/BPELImplementationProvider.java?rev=573753&r1=573752&r2=573753&view=diff
==============================================================================
--- incubator/tuscany/java/sca/modules/implementation-bpel/src/main/java/org/apache/tuscany/sca/implementation/bpel/provider/BPELImplementationProvider.java (original)
+++ incubator/tuscany/java/sca/modules/implementation-bpel/src/main/java/org/apache/tuscany/sca/implementation/bpel/provider/BPELImplementationProvider.java Fri Sep  7 16:20:24 2007
@@ -65,7 +65,8 @@
         System.out.println("Starting " + component.getName() + " " + component.getClass().getName());
         if (!odeServer.isInitialized()) odeServer.init();
         
-        odeServer.getBpelServer().register(implementation.getProcessConf());
+        //FIXME:lresende
+        //odeServer.getBpelServer().register(implementation.getProcessConf());
     }
 
     public void stop() {

Modified: incubator/tuscany/java/sca/modules/implementation-bpel/src/main/resources/META-INF/services/org.apache.tuscany.sca.contribution.processor.StAXArtifactProcessor
URL: http://svn.apache.org/viewvc/incubator/tuscany/java/sca/modules/implementation-bpel/src/main/resources/META-INF/services/org.apache.tuscany.sca.contribution.processor.StAXArtifactProcessor?rev=573753&r1=573752&r2=573753&view=diff
==============================================================================
--- incubator/tuscany/java/sca/modules/implementation-bpel/src/main/resources/META-INF/services/org.apache.tuscany.sca.contribution.processor.StAXArtifactProcessor (original)
+++ incubator/tuscany/java/sca/modules/implementation-bpel/src/main/resources/META-INF/services/org.apache.tuscany.sca.contribution.processor.StAXArtifactProcessor Fri Sep  7 16:20:24 2007
@@ -16,4 +16,4 @@
 # under the License. 
 
 # Implementation class for the artifact processor extension
-org.apache.tuscany.sca.implementation.bpel.impl.BPELArtifactProcessor;qname=http://tuscany.apache.org/xmlns/sca/1.0#implementation.bpel,model=org.apache.tuscany.sca.implementation.bpel.BPELImplementation
+org.apache.tuscany.sca.implementation.bpel.impl.BPELArtifactProcessor;qname=http://www.osoa.org/xmlns/sca/1.0#implementation.bpel,model=org.apache.tuscany.sca.implementation.bpel.BPELImplementation

Added: incubator/tuscany/java/sca/modules/implementation-bpel/src/test/java/org/apache/tuscany/sca/implementation/bpel/BPELDocumentProcessorTestCase.java
URL: http://svn.apache.org/viewvc/incubator/tuscany/java/sca/modules/implementation-bpel/src/test/java/org/apache/tuscany/sca/implementation/bpel/BPELDocumentProcessorTestCase.java?rev=573753&view=auto
==============================================================================
--- incubator/tuscany/java/sca/modules/implementation-bpel/src/test/java/org/apache/tuscany/sca/implementation/bpel/BPELDocumentProcessorTestCase.java (added)
+++ incubator/tuscany/java/sca/modules/implementation-bpel/src/test/java/org/apache/tuscany/sca/implementation/bpel/BPELDocumentProcessorTestCase.java Fri Sep  7 16:20:24 2007
@@ -0,0 +1,68 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ * 
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ * 
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.    
+ */
+
+package org.apache.tuscany.sca.implementation.bpel;
+
+import java.net.URI;
+import java.net.URL;
+
+import javax.xml.namespace.QName;
+
+import junit.framework.TestCase;
+
+import org.apache.tuscany.sca.assembly.AssemblyFactory;
+import org.apache.tuscany.sca.assembly.DefaultAssemblyFactory;
+import org.apache.tuscany.sca.contribution.DefaultModelFactoryExtensionPoint;
+import org.apache.tuscany.sca.contribution.ModelFactoryExtensionPoint;
+import org.apache.tuscany.sca.implementation.bpel.impl.BPELDocumentProcessor;
+import org.apache.tuscany.sca.interfacedef.wsdl.DefaultWSDLFactory;
+
+/**
+ * @version $Rev$ $Date$
+ */
+public class BPELDocumentProcessorTestCase extends TestCase {
+    
+    protected static final String BPEL_PROCESS_FILE = "HelloWorld.bpel";
+
+    private ModelFactoryExtensionPoint modelFactories;
+
+    @Override
+    protected void setUp() throws Exception {
+        super.setUp();
+       
+        modelFactories = new DefaultModelFactoryExtensionPoint();
+        AssemblyFactory assemblyFactory = new DefaultAssemblyFactory();
+        modelFactories.addFactory(assemblyFactory);
+        BPELFactory bpelFactory = new DefaultBPELFactory(new DefaultAssemblyFactory(), new DefaultWSDLFactory());
+        modelFactories.addFactory(bpelFactory);
+    }
+
+    public void testLoadBPELProcessDefinition() throws Exception {
+        BPELDocumentProcessor bpelDocumentProcessor = new BPELDocumentProcessor(modelFactories);
+        
+        URI processURI = getClass().getClassLoader().getResource(BPEL_PROCESS_FILE).toURI();
+        URL processLocation = getClass().getClassLoader().getResource(BPEL_PROCESS_FILE);
+        BPELProcessDefinition bpelProcessDefinition = bpelDocumentProcessor.read(null, processURI, processLocation);
+        
+        assertNotNull(bpelProcessDefinition);
+        assertEquals(new QName("http://schemas.xmlsoap.org/ws/2004/03/business-process/", "process"), bpelProcessDefinition.getName());
+        assertEquals(processLocation, bpelProcessDefinition.getLocation());
+        assertEquals(true, bpelProcessDefinition.isUnresolved());
+    }
+}

Propchange: incubator/tuscany/java/sca/modules/implementation-bpel/src/test/java/org/apache/tuscany/sca/implementation/bpel/BPELDocumentProcessorTestCase.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/tuscany/java/sca/modules/implementation-bpel/src/test/java/org/apache/tuscany/sca/implementation/bpel/BPELDocumentProcessorTestCase.java
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Added: incubator/tuscany/java/sca/modules/implementation-bpel/src/test/java/org/apache/tuscany/sca/implementation/bpel/BPELImplementationProcessorTestCase.java
URL: http://svn.apache.org/viewvc/incubator/tuscany/java/sca/modules/implementation-bpel/src/test/java/org/apache/tuscany/sca/implementation/bpel/BPELImplementationProcessorTestCase.java?rev=573753&view=auto
==============================================================================
--- incubator/tuscany/java/sca/modules/implementation-bpel/src/test/java/org/apache/tuscany/sca/implementation/bpel/BPELImplementationProcessorTestCase.java (added)
+++ incubator/tuscany/java/sca/modules/implementation-bpel/src/test/java/org/apache/tuscany/sca/implementation/bpel/BPELImplementationProcessorTestCase.java Fri Sep  7 16:20:24 2007
@@ -0,0 +1,122 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ * 
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ * 
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.    
+ */
+
+package org.apache.tuscany.sca.implementation.bpel;
+
+import java.io.StringReader;
+
+import javax.xml.namespace.QName;
+import javax.xml.stream.XMLInputFactory;
+import javax.xml.stream.XMLStreamConstants;
+import javax.xml.stream.XMLStreamReader;
+
+import junit.framework.TestCase;
+
+import org.apache.tuscany.sca.assembly.AssemblyFactory;
+import org.apache.tuscany.sca.assembly.DefaultAssemblyFactory;
+import org.apache.tuscany.sca.assembly.xml.Constants;
+import org.apache.tuscany.sca.contribution.DefaultModelFactoryExtensionPoint;
+import org.apache.tuscany.sca.contribution.ModelFactoryExtensionPoint;
+import org.apache.tuscany.sca.implementation.bpel.impl.BPELImplementationProcessor;
+import org.apache.tuscany.sca.interfacedef.java.DefaultJavaInterfaceFactory;
+import org.apache.tuscany.sca.interfacedef.java.JavaInterfaceFactory;
+
+/**
+ * @version $Rev$ $Date$
+ */
+public class BPELImplementationProcessorTestCase extends TestCase {
+    
+    protected static final QName IMPLEMENTATION_BPEL = new QName(Constants.SCA10_NS, "implementation.bpel");
+
+    private static final String COMPOSITE =
+        "<?xml version=\"1.0\" encoding=\"ASCII\"?>" 
+        + "<composite xmlns=\"http://www.osoa.org/xmlns/sca/1.0\" xmlns:hns=\"http://tuscany.apache.org/implementation/bpel/example/helloworld\" targetNamespace=\"http://bpel\" name=\"bpel\">"
+            + " <component name=\"BPELHelloWorldComponent\">"
+            + "   <implementation.bpel process=\"hns:HelloWorld\" />"
+            + "</component>";
+
+    private static final String COMPOSITE_INVALID =
+        "<?xml version=\"1.0\" encoding=\"ASCII\"?>" 
+            + "<composite xmlns=\"http://www.osoa.org/xmlns/sca/1.0\" xmlns:hns=\"http://tuscany.apache.org/implementation/bpel/example/helloworld\" targetNamespace=\"http://bpel\" name=\"bpel\">"
+            + " <component name=\"BPELHelloWorldComponent\">"
+            + "   <implementation.bpel/>"
+            + "</component>";
+
+    private XMLInputFactory xmlFactory;
+    private ModelFactoryExtensionPoint modelFactories;
+
+    @Override
+    protected void setUp() throws Exception {
+        super.setUp();
+        xmlFactory = XMLInputFactory.newInstance();
+        
+        modelFactories = new DefaultModelFactoryExtensionPoint();
+        AssemblyFactory assemblyFactory = new DefaultAssemblyFactory();
+        modelFactories.addFactory(assemblyFactory);
+        JavaInterfaceFactory javaFactory = new DefaultJavaInterfaceFactory();
+        modelFactories.addFactory(javaFactory);
+    }
+
+    /**
+     * Test parsing valid composite definition. Valid coposite populated with correct values expected.
+     * @throws Exception
+     */
+    public void testLoadValidComposite() throws Exception {
+        XMLStreamReader reader = xmlFactory.createXMLStreamReader(new StringReader(COMPOSITE));
+        
+        BPELImplementationProcessor bpelProcessor = new BPELImplementationProcessor(modelFactories);
+        
+        while(true) {
+            int event = reader.next();
+            if(event == XMLStreamConstants.START_ELEMENT && IMPLEMENTATION_BPEL.equals(reader.getName())) {
+                break;
+            }
+        }
+
+        BPELImplementation implementation = bpelProcessor.read(reader);
+        
+        assertNotNull(implementation);
+        assertEquals(new QName("http://tuscany.apache.org/implementation/bpel/example/helloworld", "HelloWorld"), implementation.getProcess());
+    }
+
+    /**
+     * Test parsing invalid composite definition. Exception should be thrown
+     * @throws Exception
+     */
+    public void testLoadInvalidComposite() throws Exception {
+        XMLStreamReader reader = xmlFactory.createXMLStreamReader(new StringReader(COMPOSITE_INVALID));
+
+        BPELImplementationProcessor bpelProcessor = new BPELImplementationProcessor(modelFactories);
+        
+        while(true) {
+            int event = reader.next();
+            if(event == XMLStreamConstants.START_ELEMENT && IMPLEMENTATION_BPEL.equals(reader.getName())) {
+                break;
+            }
+        }
+
+        try {
+            bpelProcessor.read(reader);
+            
+            fail("InvalidException should have been thrown");
+        } catch(Exception e) {
+            assertTrue(true);
+        }
+    }    
+}

Propchange: incubator/tuscany/java/sca/modules/implementation-bpel/src/test/java/org/apache/tuscany/sca/implementation/bpel/BPELImplementationProcessorTestCase.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/tuscany/java/sca/modules/implementation-bpel/src/test/java/org/apache/tuscany/sca/implementation/bpel/BPELImplementationProcessorTestCase.java
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Modified: incubator/tuscany/java/sca/modules/implementation-bpel/src/test/java/org/apache/tuscany/sca/implementation/bpel/BPELTestCase.java
URL: http://svn.apache.org/viewvc/incubator/tuscany/java/sca/modules/implementation-bpel/src/test/java/org/apache/tuscany/sca/implementation/bpel/BPELTestCase.java?rev=573753&r1=573752&r2=573753&view=diff
==============================================================================
--- incubator/tuscany/java/sca/modules/implementation-bpel/src/test/java/org/apache/tuscany/sca/implementation/bpel/BPELTestCase.java (original)
+++ incubator/tuscany/java/sca/modules/implementation-bpel/src/test/java/org/apache/tuscany/sca/implementation/bpel/BPELTestCase.java Fri Sep  7 16:20:24 2007
@@ -21,8 +21,6 @@
 
 import junit.framework.TestCase;
 
-import org.apache.tuscany.sca.host.embedded.SCADomain;
-
 /**
  * Tests the BPEL service
  * 
@@ -30,8 +28,7 @@
  */
 public class BPELTestCase extends TestCase {
 
-    private SCADomain scaDomain;
-    private BPEL bpelService;
+    //private SCADomain scaDomain;
     
     /**
      * @throws java.lang.Exception

Modified: incubator/tuscany/java/sca/modules/implementation-bpel/src/test/resources/helloworld.composite
URL: http://svn.apache.org/viewvc/incubator/tuscany/java/sca/modules/implementation-bpel/src/test/resources/helloworld.composite?rev=573753&r1=573752&r2=573753&view=diff
==============================================================================
--- incubator/tuscany/java/sca/modules/implementation-bpel/src/test/resources/helloworld.composite (original)
+++ incubator/tuscany/java/sca/modules/implementation-bpel/src/test/resources/helloworld.composite Fri Sep  7 16:20:24 2007
@@ -18,18 +18,17 @@
     * under the License.    
 -->
 <composite xmlns="http://www.osoa.org/xmlns/sca/1.0"
-    xmlns:tuscany="http://tuscany.apache.org/xmlns/sca/1.0"
 	targetNamespace="http://bpel"
     xmlns:hns="http://tuscany.apache.org/implementation/bpel/example/helloworld"
     name="bpel">
 
     <service name="BPELHelloWorldService" promote="BPELHelloWorldComponent">
-          <interface.wsdl
-                  interface="http://tuscany.apache.org/implementation/bpel/example/helloworld.wsd#wsdl.interface(HelloPortType)" />
+          <interface.wsdl interface="http://tuscany.apache.org/implementation/bpel/example/helloworld.wsd#wsdl.interface(HelloPortType)" />
     </service>
     
     <component name="BPELHelloWorldComponent">
-        <tuscany:implementation.bpel process="hns:HelloWorld" file="HelloWorld.bpel"/>
+        <!-- implementation.bpel process="hns:HelloWorld" file="HelloWorld.bpel"/ -->
+        <implementation.bpel process="hns:HelloWorld"/>
     </component>
 
 </composite>



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