You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@ode.apache.org by ms...@apache.org on 2006/11/29 03:34:54 UTC

svn commit: r480342 - in /incubator/ode/trunk: ./ bpel-api/ bpel-api/src/main/java/org/apache/ode/bpel/evt/ bpel-api/src/main/java/org/apache/ode/bpel/iapi/ bpel-api/src/main/xsd/ bpel-dd/ bpel-schemas/ bpel-schemas/src/main/xsd/

Author: mszefler
Date: Tue Nov 28 18:34:53 2006
New Revision: 480342

URL: http://svn.apache.org/viewvc?view=rev&rev=480342
Log:
Moved all XmlBean code-generation into bpel-schemas module to speed-up build, simplify
maven's life.


Added:
    incubator/ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/iapi/ProcessState.java
    incubator/ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/iapi/ProcessStoreEvent.java
    incubator/ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/iapi/ProcessStoreListener.java
    incubator/ode/trunk/bpel-schemas/src/main/xsd/
      - copied from r477383, incubator/ode/trunk/bpel-dd/src/main/xsd/
    incubator/ode/trunk/bpel-schemas/src/main/xsd/dd.xsd
      - copied unchanged from r480341, incubator/ode/trunk/bpel-dd/src/main/xsd/dd.xsd
    incubator/ode/trunk/bpel-schemas/src/main/xsd/dd.xsdconfig
      - copied unchanged from r480341, incubator/ode/trunk/bpel-dd/src/main/xsd/dd.xsdconfig
    incubator/ode/trunk/bpel-schemas/src/main/xsd/pmapi.xsd
      - copied unchanged from r476340, incubator/ode/trunk/bpel-api/src/main/xsd/pmapi.xsd
    incubator/ode/trunk/bpel-schemas/src/main/xsd/pmapi.xsdconfig
      - copied unchanged from r476340, incubator/ode/trunk/bpel-api/src/main/xsd/pmapi.xsdconfig
Removed:
    incubator/ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/iapi/DeploymentUnit.java
    incubator/ode/trunk/bpel-api/src/main/xsd/pmapi.xsd
    incubator/ode/trunk/bpel-api/src/main/xsd/pmapi.xsdconfig
    incubator/ode/trunk/bpel-dd/
Modified:
    incubator/ode/trunk/bpel-api/pom.xml
    incubator/ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/evt/BpelEvent.java
    incubator/ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/iapi/BpelServer.java
    incubator/ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/iapi/ContextException.java
    incubator/ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/iapi/ProcessConf.java
    incubator/ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/iapi/ProcessStore.java
    incubator/ode/trunk/bpel-schemas/pom.xml
    incubator/ode/trunk/pom.xml

Modified: incubator/ode/trunk/bpel-api/pom.xml
URL: http://svn.apache.org/viewvc/incubator/ode/trunk/bpel-api/pom.xml?view=diff&rev=480342&r1=480341&r2=480342
==============================================================================
--- incubator/ode/trunk/bpel-api/pom.xml (original)
+++ incubator/ode/trunk/bpel-api/pom.xml Tue Nov 28 18:34:53 2006
@@ -42,7 +42,7 @@
         </dependency>
         <dependency>
             <groupId>org.apache.ode</groupId>
-            <artifactId>ode-bpel-dd</artifactId>
+            <artifactId>ode-bpel-schemas</artifactId>
         </dependency>
         
 	<dependency>
@@ -50,16 +50,6 @@
             <artifactId>wsdl4j</artifactId>
         </dependency>
 
-	<dependency>
-            <groupId>xmlbeans</groupId>
-            <artifactId>xbean</artifactId>
-        </dependency>
-	
-	<dependency>
-            <groupId>xmlbeans</groupId>
-            <artifactId>xmlpublic</artifactId>
-        </dependency>
-        
         <dependency>
           <groupId>stax</groupId>
           <artifactId>stax-api</artifactId>
@@ -67,30 +57,4 @@
 
 
     </dependencies>
-    <build>
-        <plugins>
-            <plugin>
-                <groupId>org.codehaus.mojo</groupId>
-                <artifactId>xmlbeans-maven-plugin</artifactId>
-                <executions>
-                    <execution>
-                        <phase>generate-sources</phase>
-                        <goals><goal>xmlbeans</goal></goals>
-                        <configuration>
-                            <schemaDirectory>src/main/xsd</schemaDirectory>
-                            <javaSource>1.5</javaSource>
-                            <outputJar>${basedir}/target/xmlbeans.jar</outputJar>
-                            <xmlConfigs>
-                                <xmlConfig implementation="java.io.File">src/main/xsd/pmapi.xsdconfig</xmlConfig>
-                            </xmlConfigs>
-                            <!--staleFile>stale</staleFile-->
-                            <quiet>true</quiet>
-                            <failonerror>true</failonerror>
-							<outputJar>target/xmlbeans.jar</outputJar>
-                        </configuration>
-                    </execution>
-                </executions>
-            </plugin>
-        </plugins>
-    </build>
 </project>

Modified: incubator/ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/evt/BpelEvent.java
URL: http://svn.apache.org/viewvc/incubator/ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/evt/BpelEvent.java?view=diff&rev=480342&r1=480341&r2=480342
==============================================================================
--- incubator/ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/evt/BpelEvent.java (original)
+++ incubator/ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/evt/BpelEvent.java Tue Nov 28 18:34:53 2006
@@ -29,64 +29,56 @@
  */
 public abstract class BpelEvent implements Serializable {
 
-  private Date _timestamp = new Date();
-  private int _lineNo = -1;
+    public enum TYPE {
+        dataHandling, activityLifecycle, scopeHandling, instanceLifecycle, correlation;
+    }
 
-  public int getLineNo() {
-    return _lineNo;
-  }
-
-  public void setLineNo(int lineNo) {
-    _lineNo = lineNo;
-  }
-
-  public Date getTimestamp() {
-    return _timestamp;
-  }
-
-  public void setTimestamp(Date tstamp) {
-    _timestamp = tstamp;
-  }
-
-  public String toString() {
-    StringBuilder sb = new StringBuilder("\n" + eventName(this) + ":");
-
-    Method[] methods = getClass().getMethods();
-    for (Method method : methods) {
-      if (method.getName().startsWith("get")
-              && method.getParameterTypes().length == 0) {
-        try {
-          String field = method.getName().substring(3);
-          Object value = method.invoke(this, ArrayUtils.EMPTY_OBJECT_ARRAY);
-          if (value == null) {
-            continue;
-          }
-          sb.append("\n\t")
-                  .append(field)
-                  .append(" = ")
-                  .append(value == null ? "null" : value.toString());
-        } catch (Exception e) {
-          // ignore
-        }
-      }
+    private Date _timestamp = new Date();
+
+    private int _lineNo = -1;
+
+    public int getLineNo() {
+        return _lineNo;
+    }
+
+    public void setLineNo(int lineNo) {
+        _lineNo = lineNo;
     }
-    return sb.toString();
-  }
 
-  public static String eventName(BpelEvent event){
-    String name = event.getClass().getName();
-    return name.substring(name.lastIndexOf('.') + 1);
-  }
+    public Date getTimestamp() {
+        return _timestamp;
+    }
+
+    public void setTimestamp(Date tstamp) {
+        _timestamp = tstamp;
+    }
 
-  public enum TYPE {
-    dataHandling(1), activityLifecycle(2), scopeHandling(4), instanceLifecycle(8), correlation(16);
+    public String toString() {
+        StringBuilder sb = new StringBuilder("\n" + eventName(this) + ":");
+
+        Method[] methods = getClass().getMethods();
+        for (Method method : methods) {
+            if (method.getName().startsWith("get") && method.getParameterTypes().length == 0) {
+                try {
+                    String field = method.getName().substring(3);
+                    Object value = method.invoke(this, ArrayUtils.EMPTY_OBJECT_ARRAY);
+                    if (value == null) {
+                        continue;
+                    }
+                    sb.append("\n\t").append(field).append(" = ").append(value == null ? "null" : value.toString());
+                } catch (Exception e) {
+                    // ignore
+                }
+            }
+        }
+        return sb.toString();
+    }
 
-    public int bitset = 0;
-    TYPE(int bitset) {
-      this.bitset = bitset;
+    public static String eventName(BpelEvent event) {
+        String name = event.getClass().getName();
+        return name.substring(name.lastIndexOf('.') + 1);
     }
-  }
 
-  public abstract TYPE getType();
+    public abstract TYPE getType();
 
 }

Modified: incubator/ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/iapi/BpelServer.java
URL: http://svn.apache.org/viewvc/incubator/ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/iapi/BpelServer.java?view=diff&rev=480342&r1=480341&r2=480342
==============================================================================
--- incubator/ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/iapi/BpelServer.java (original)
+++ incubator/ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/iapi/BpelServer.java Tue Nov 28 18:34:53 2006
@@ -18,8 +18,6 @@
  */
 package org.apache.ode.bpel.iapi;
 
-import org.apache.ode.bpel.pmapi.BpelManagementFacade;
-
 import javax.xml.namespace.QName;
 
 
@@ -106,27 +104,17 @@
     BpelEngine getEngine();
 
     /**
-     * Activate a process.
-     * @param pid process to load
-     * @param sticky is this change sticky, i.e. will the process be activated
-     *        on restart.
+     * Register a process with the server.
+     * @param pid process to register
      * @throws BpelEngineException
      */
-    void load(QName pid, boolean sticky) throws BpelEngineException;
+    void register(ProcessConf conf) throws BpelEngineException;
 
     /**
-     * Deactivate a process.
-     * @param pid process to unload
-     * @param sticky whether the change is sticky, i.e. will the process be
-     *        deactivated on restart
+     * Unregister a process from the server. 
+     * @param pid process to unregister
      * @throws BpelEngineException
      */
-    void unload(QName pid, boolean sticky) throws BpelEngineException;
-
-    /**
-     * Get the BPEL management interface.
-     * @return BPEL management interface
-     */
-    BpelManagementFacade getBpelManagementFacade();
+    void unregister(QName pid) throws BpelEngineException;
 
 }

Modified: incubator/ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/iapi/ContextException.java
URL: http://svn.apache.org/viewvc/incubator/ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/iapi/ContextException.java?view=diff&rev=480342&r1=480341&r2=480342
==============================================================================
--- incubator/ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/iapi/ContextException.java (original)
+++ incubator/ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/iapi/ContextException.java Tue Nov 28 18:34:53 2006
@@ -25,14 +25,18 @@
  */
 public class ContextException extends RuntimeException {
 
-	private static final long serialVersionUID = -3359898226556748371L;
+    private static final long serialVersionUID = -3359898226556748371L;
 
-	public ContextException() {
-		super();
-	}
+    public ContextException() {
+        super();
+    }
 
-	public ContextException(String string, Exception ex) {
-		super(string, ex);
-	}
+    public ContextException(String string) {
+        this(string, null);
+    }
+
+    public ContextException(String string, Throwable ex) {
+        super(string, ex);
+    }
 
 }

Modified: incubator/ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/iapi/ProcessConf.java
URL: http://svn.apache.org/viewvc/incubator/ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/iapi/ProcessConf.java?view=diff&rev=480342&r1=480341&r2=480342
==============================================================================
--- incubator/ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/iapi/ProcessConf.java (original)
+++ incubator/ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/iapi/ProcessConf.java Tue Nov 28 18:34:53 2006
@@ -1,37 +1,127 @@
+/*
+ * 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.ode.bpel.iapi;
 
+import org.apache.ode.bpel.evt.BpelEvent.TYPE;
 import org.w3c.dom.Node;
 
+import javax.wsdl.Definition;
 import javax.xml.namespace.QName;
 import java.io.File;
+import java.io.InputStream;
 import java.util.Date;
+import java.util.List;
 import java.util.Map;
 
 /**
+ * Deployed process configuration. IMPORTANT: Implementations of this class <em>MUST BE IMMUTABLE</em>,
+ * otherwise the engine will get confused.  
+ * 
  * @author mriou <mriou at apache dot org>
  */
 public interface ProcessConf {
 
+    /**
+     * Get the process id, generally the same as the type.
+     * @return process id.
+     */
     QName getProcessId();
+    
+    /**
+     * Get the process type (BPEL definition name).
+     * @return
+     */
+    QName getType();
 
+    /**
+     * Is this a <em>transient</em> process? Transient processes are not persisted in the store.
+     * @return <code>true</code> if this is a transient process.
+     */
+    boolean isTransient();
+    
+    /**
+     * Get the CBP stream. 
+     * @return new stream to the CBP file.
+     */
+    InputStream getCBPInputStream();
+   
+    /**
+     * Get the date of deployment.
+     * @return
+     */
     Date getDeployDate();
 
+    /**
+     * Get the userid of the deployer.
+     * @return
+     */
     String getDeployer();
 
-    boolean isActive();
+    /**
+     * Get the state of the process. 
+     * @return process state.
+     */
+    ProcessState getState();
+    
 
-    File[] getFiles();
+    /**
+     * Get the files associated with the deployment.
+     * @return
+     */
+    List<File> getFiles();
 
+    /**
+     * Get the deployment properties. 
+     * @return
+     */
     Map<QName, Node> getProperties();
 
     /**
      * Gets the name of the package into which the process is deployed.
      * @return package name
      */
-    String getProcessPackage();
+    String getPackage();
+    
+    /**
+     * Gets the WSDL definition used in a process into which a service is defined.
+     * @param processId
+     * @param serviceName
+     * @return definition
+     */
+    Definition getDefinitionForService(QName serviceName);
+
+   
+    
+    /**
+     * Gets the list of endpoints a process should provide.
+     * @param processId
+     * @return map of partner link names and associated enpoints
+     */
+    Map<String, Endpoint> getProvideEndpoints();
 
     /**
-     * @return true if the process should be executed only in-memory without being persisted
+     * Gets the list of endpoints a process invokes.
+     * @param processId
+     * @return map of partner link names and associated enpoints
      */
-    boolean isInMemory();
-}
+    Map<String, Endpoint> getInvokeEndpoints();
+
+    boolean isEventEnabled(List<String> scopeNames, TYPE type);
+    
+}
\ No newline at end of file

Added: incubator/ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/iapi/ProcessState.java
URL: http://svn.apache.org/viewvc/incubator/ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/iapi/ProcessState.java?view=auto&rev=480342
==============================================================================
--- incubator/ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/iapi/ProcessState.java (added)
+++ incubator/ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/iapi/ProcessState.java Tue Nov 28 18:34:53 2006
@@ -0,0 +1,16 @@
+package org.apache.ode.bpel.iapi;
+
+/**
+ * The user-selectable states of a process in the configuration store.
+ * @author mszefler
+ */
+public enum ProcessState {
+    /** Process can create new instances and execute old instances. */
+    ACTIVE,
+    
+    /** Process can execute old instances, but cannot create new instances. */
+    RETIRED,
+    
+    /** Process cannot exeucte old nor create new instances. */
+    DISABLED
+}

Modified: incubator/ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/iapi/ProcessStore.java
URL: http://svn.apache.org/viewvc/incubator/ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/iapi/ProcessStore.java?view=diff&rev=480342&r1=480341&r2=480342
==============================================================================
--- incubator/ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/iapi/ProcessStore.java (original)
+++ incubator/ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/iapi/ProcessStore.java Tue Nov 28 18:34:53 2006
@@ -1,25 +1,38 @@
-package org.apache.ode.bpel.iapi;
+/*
+ * 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.
+ */
 
-import org.w3c.dom.Node;
+package org.apache.ode.bpel.iapi;
 
-import javax.wsdl.Definition;
-import javax.xml.namespace.QName;
 import java.io.File;
 import java.util.Collection;
 import java.util.List;
 import java.util.Map;
 
+import javax.wsdl.Definition;
+import javax.xml.namespace.QName;
+
+import org.w3c.dom.Node;
+
 /**
  * @author mriou <mriou at apache dot org>
  */
 public interface ProcessStore {
-
-    /**
-     * Gets the directory where all processes are deployed.
-     * @return directory file
-     */
-    File getDeploymentDir();
-
     /**
      * Deploys a process from the filesystem.
      * @param deploymentUnitDirectory directory containing all deployment files
@@ -39,72 +52,56 @@
      * to a directory name on the file system).
      * @return an array of package names
      */
-    String[] listDeployedPackages();
+    Collection<String> getPackages();
 
     /**
      * Lists all processe ids in a given package.
      * @return an array of process id QNames
      */
-    QName[] listProcesses(String packageName);
+    List<QName> listProcesses(String packageName);
 
     /**
-     * Get the list of all active processes known to the store.
-     * @return list of active processes qnames with their compiled definition
+     * Get the list of processes known to the store.
+     * @return list of  processes qnames with their compiled definition
      */
-    Map<QName, byte[]> getActiveProcesses();
+    List<QName> getProcesses();
 
-    /**
-     * Gets the list of endpoints a process should provide.
-     * @param processId
-     * @return map of partner link names and associated enpoints
-     */
-    Map<String, Endpoint> getProvideEndpoints(QName processId);
 
     /**
-     * Gets the list of endpoints a process invokes.
+     * Gets all the details of a process configuration (properties, deploy dates, ...)
      * @param processId
-     * @return map of partner link names and associated enpoints
+     * @return process configuration details
      */
-    Map<String, Endpoint> getInvokeEndpoints(QName processId);
+    ProcessConf getProcessConfiguration(QName processId);
 
+   
     /**
-     * Marks a process as active or inactive
-     * @param processId
-     * @param status true for active, false for inactive
+     * Register a configuration store listener.
+     * @param psl  {@link ProcessStoreListener} 
      */
-    void markActive(QName processId, boolean status);
-
+    void registerListener(ProcessStoreListener psl);
+    
     /**
-     * Gets the list of message interceptor class names configured on a process.
-     * @param processId
-     * @return list of interceptor class names
+     * Unregister a configuration store listener.
+     * @param psl {@link ProcessStoreListener} 
      */
-    List<String> getMexInterceptors(QName processId);
+    void unregisterListener(ProcessStoreListener psl);
 
-    /**
-     * Gets all the details of a process configuration (properties, deploy dates, ...)
-     * @param processId
-     * @return process configuration details
-     */
-    ProcessConf getProcessConfiguration(QName processId);
 
     /**
-     * Gets the WSDL definition used in a process into which a service is defined.
+     * Set a process property.
      * @param processId
-     * @param serviceName
-     * @return definition
+     * @param propName 
+     * @param value
      */
-    Definition getDefinitionForService(QName processId, QName serviceName);
-
-    void setProperty(QName processId, String name, String namespace, String value);
-    void setProperty(QName processId, String name, String namespace, Node value);
-
+    void setProperty(QName pid, QName propName, String value);
+    
+    void setProperty(QName pid, QName propName, Node value);
+    
     /**
-     * Gets the event setting for an activity that would be in a given process
-     * and having the provided scope hierarchy.
+     * Marks a process as active / retired or disabled
      * @param processId
-     * @param scopeNames names of parent scopes starting from the directly enclosing scope to the highest scope
-     * @return enable event types
+     * @param status true for active, false for inactive
      */
-    List<String> getEventsSettings(QName processId, List<String> scopeNames);
+    void setState(QName pid, ProcessState state);
 }

Added: incubator/ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/iapi/ProcessStoreEvent.java
URL: http://svn.apache.org/viewvc/incubator/ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/iapi/ProcessStoreEvent.java?view=auto&rev=480342
==============================================================================
--- incubator/ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/iapi/ProcessStoreEvent.java (added)
+++ incubator/ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/iapi/ProcessStoreEvent.java Tue Nov 28 18:34:53 2006
@@ -0,0 +1,71 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *    http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ */
+package org.apache.ode.bpel.iapi;
+
+import javax.xml.namespace.QName;
+
+/**
+ * Event generated by the process store.
+ * @author mszefler
+ */
+public class ProcessStoreEvent {
+    public enum Type {
+        /** A process was deployed to the store. */
+        DEPLOYED,
+        
+        /** A process was undeployed to from the store. */
+        UNDEPLOYED,
+        
+        /** A process has been retired (i.e. it should no longer create new instances. */
+        RETIRED,
+        
+        /** 
+         * A process that was previously disabled or retired has become activated. This
+         * event is also sent whenver an active process is "discovered" 
+         */
+        ACTVIATED,
+        
+        /** A process has been disabled: it should no longer execute for new or old instances. */
+        DISABLED,
+        
+        /** A process property was changed. */
+        PROPERTY_CHANGED
+    }
+
+    /**
+     * Event type. 
+     * @see Type
+     */
+    public final Type type;
+    
+    /**
+     * Process identifier.
+     */
+    public final QName pid; 
+    
+    public ProcessStoreEvent(Type type, QName pid) {
+        this.type = type;
+        this.pid = pid;
+    }
+    
+    @Override
+    public String toString() {
+        return "{ProcessStoreEvent#" + type + ":" + pid +"}";
+    }
+}

Added: incubator/ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/iapi/ProcessStoreListener.java
URL: http://svn.apache.org/viewvc/incubator/ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/iapi/ProcessStoreListener.java?view=auto&rev=480342
==============================================================================
--- incubator/ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/iapi/ProcessStoreListener.java (added)
+++ incubator/ode/trunk/bpel-api/src/main/java/org/apache/ode/bpel/iapi/ProcessStoreListener.java Tue Nov 28 18:34:53 2006
@@ -0,0 +1,29 @@
+/*
+ * 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.ode.bpel.iapi;
+
+/** 
+ * Process configuration store listener interface. 
+ */
+public interface ProcessStoreListener {
+    
+    public void onProcessStoreEvent(ProcessStoreEvent event);
+
+}

Modified: incubator/ode/trunk/bpel-schemas/pom.xml
URL: http://svn.apache.org/viewvc/incubator/ode/trunk/bpel-schemas/pom.xml?view=diff&rev=480342&r1=480341&r2=480342
==============================================================================
--- incubator/ode/trunk/bpel-schemas/pom.xml (original)
+++ incubator/ode/trunk/bpel-schemas/pom.xml Tue Nov 28 18:34:53 2006
@@ -30,4 +30,37 @@
     <version>2.0-SNAPSHOT</version>
   </parent>
   <version>2.0-SNAPSHOT</version>
+
+
+  <build>
+    <plugins>
+      <plugin>
+        <groupId>org.codehaus.mojo</groupId>
+        <artifactId>xmlbeans-maven-plugin</artifactId>
+        <executions>
+          <execution>
+            <phase>generate-sources</phase>
+            <goals><goal>xmlbeans</goal></goals>
+            <configuration>
+              <javaSource>1.5</javaSource>
+
+              <!-- The following is needed for Eclipse build. -->
+              <outputJar>${basedir}/target/xmlbeans.jar</outputJar>
+              <schemaDirectory>src/main/xsd</schemaDirectory>
+              <xmlConfigs>
+                <xmlConfig implementation="java.io.File">src/main/xsd/dd.xsdconfig</xmlConfig>
+                <xmlConfig implementation="java.io.File">src/main/xsd/pmapi.xsdconfig</xmlConfig>
+              </xmlConfigs>
+              <quiet>true</quiet>
+              <failonerror>true</failonerror>
+                                <!-- This is needed for eclipse project to work -->
+                          <outputJar>target/xmlbeans.jar</outputJar>
+            </configuration>
+          </execution>
+        </executions>
+      </plugin>
+
+    </plugins>
+
+  </build>
 </project>

Modified: incubator/ode/trunk/pom.xml
URL: http://svn.apache.org/viewvc/incubator/ode/trunk/pom.xml?view=diff&rev=480342&r1=480341&r2=480342
==============================================================================
--- incubator/ode/trunk/pom.xml (original)
+++ incubator/ode/trunk/pom.xml Tue Nov 28 18:34:53 2006
@@ -86,6 +86,7 @@
         <derbyVersion>10.1.2.1</derbyVersion>
         <quartzVersion>1.5.1</quartzVersion>
         <xstreamVersion>1.2</xstreamVersion>
+	<hsqlDbVersion>1.8.0.7</hsqlDbVersion>
 
         <!--
         | Build number used by the intalio:release plugin
@@ -111,11 +112,9 @@
 
         <module>jacob</module>
 
-        <module>bpel-store</module>
         <module>bpel-scripts</module>
         <module>bpel-schemas</module>
         <module>bpel-obj</module>
-        <module>bpel-dd</module>
         <module>bpel-api</module>
         <module>bpel-dao</module>
         <module>bpel-api-jca</module>
@@ -127,6 +126,7 @@
         <module>bpel-test</module>
 
         <module>dao-hibernate</module>
+        <module>bpel-store</module>
         <module>dao-hibernate-db-derby</module>
         <!-- module>dao-memory</module -->
 
@@ -386,11 +386,6 @@
             </dependency>
             <dependency>
                 <groupId>org.apache.ode</groupId>
-                <artifactId>ode-bpel-dd</artifactId>
-                <version>${project.version}</version>
-            </dependency>
-            <dependency>
-                <groupId>org.apache.ode</groupId>
                 <artifactId>ode-bpel-obj</artifactId>
                 <version>${project.version}</version>
             </dependency>
@@ -610,6 +605,12 @@
                 <groupId>jaxen</groupId>
                 <artifactId>jaxen</artifactId>
                 <version>${jaxenVersion}</version>
+            </dependency>
+
+            <dependency>
+                <groupId>hsqldb</groupId>
+                <artifactId>hsqldb</artifactId>
+                <version>${hsqlDbVersion}</version>
             </dependency>
 
             <!--