You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@tuscany.apache.org by gi...@apache.org on 2008/04/30 14:38:54 UTC

svn commit: r652371 - in /incubator/tuscany/java/sca: demos/workpool-distributed/ demos/workpool-distributed/src/main/java/node/ demos/workpool-distributed/src/main/java/workpool/ modules/node-impl/src/main/java/org/apache/tuscany/sca/node/impl/ tools/...

Author: giorgio
Date: Wed Apr 30 05:38:54 2008
New Revision: 652371

URL: http://svn.apache.org/viewvc?rev=652371&view=rev
Log:
M    sca/demos/workpool-distributed/src/main/java/node/WorkpoolDaemon.java
M    sca/demos/workpool-distributed/src/main/java/workpool/WorkerManager.java
M    sca/demos/workpool-distributed/src/main/java/workpool/WorkerManagerImpl.java
M    sca/demos/workpool-distributed/pom.xml
M    sca/modules/node-impl/src/main/java/org/apache/tuscany/sca/node/impl/SCANodeImpl.java

Modified:
    incubator/tuscany/java/sca/demos/workpool-distributed/pom.xml
    incubator/tuscany/java/sca/demos/workpool-distributed/src/main/java/node/WorkpoolDaemon.java
    incubator/tuscany/java/sca/demos/workpool-distributed/src/main/java/workpool/WorkerManager.java
    incubator/tuscany/java/sca/demos/workpool-distributed/src/main/java/workpool/WorkerManagerImpl.java
    incubator/tuscany/java/sca/modules/node-impl/src/main/java/org/apache/tuscany/sca/node/impl/SCANodeImpl.java
    incubator/tuscany/java/sca/tools/eclipse/features/feature/.project
    incubator/tuscany/java/sca/tools/eclipse/plugins/core/.classpath
    incubator/tuscany/java/sca/tools/eclipse/site/updatesite/.project

Modified: incubator/tuscany/java/sca/demos/workpool-distributed/pom.xml
URL: http://svn.apache.org/viewvc/incubator/tuscany/java/sca/demos/workpool-distributed/pom.xml?rev=652371&r1=652370&r2=652371&view=diff
==============================================================================
--- incubator/tuscany/java/sca/demos/workpool-distributed/pom.xml (original)
+++ incubator/tuscany/java/sca/demos/workpool-distributed/pom.xml Wed Apr 30 05:38:54 2008
@@ -59,7 +59,12 @@
 			<artifactId>antlr</artifactId>
 			<version>2.7.1</version>
 		</dependency>
-
+	<dependency>
+	  <groupId>commons-daemon</groupId>
+  	<artifactId>commons-daemon</artifactId>
+  	<version>1.0.1</version>
+  	</dependency>
+	
 		<dependency>
 			<groupId>antlr</groupId>
 			<artifactId>stringtemplate</artifactId>

Modified: incubator/tuscany/java/sca/demos/workpool-distributed/src/main/java/node/WorkpoolDaemon.java
URL: http://svn.apache.org/viewvc/incubator/tuscany/java/sca/demos/workpool-distributed/src/main/java/node/WorkpoolDaemon.java?rev=652371&r1=652370&r2=652371&view=diff
==============================================================================
--- incubator/tuscany/java/sca/demos/workpool-distributed/src/main/java/node/WorkpoolDaemon.java (original)
+++ incubator/tuscany/java/sca/demos/workpool-distributed/src/main/java/node/WorkpoolDaemon.java Wed Apr 30 05:38:54 2008
@@ -44,6 +44,8 @@
 import org.apache.tuscany.sca.node.SCANode;
 import org.apache.tuscany.sca.node.SCANodeFactory;
 import org.apache.tuscany.sca.node.impl.SCANodeImpl;
+import org.apache.tuscany.sca.node.management.SCANodeManagerInitService;
+
 import java.net.URI;
 
 import workpool.WorkerManager;
@@ -183,8 +185,8 @@
             WorkpoolService workpoolService = node.getDomain().getService(
                     WorkpoolService.class, "WorkpoolServiceComponent");
             workpoolService.start();
-            NodeManagerInitService nodeInit = node.getDomain().getService(
-                    NodeManagerInitService.class,
+            SCANodeManagerInitService nodeInit = node.getDomain().getService(
+                    SCANodeManagerInitService.class,
                     "WorkpoolManagerComponent/NodeManagerInitService");
             nodeInit.setNode(node);
             WorkpoolManager workpoolManager = node.getDomain().getService(
@@ -210,33 +212,33 @@
 
         }
         if (nodeName.equals("nodeB")) {
-            NodeManagerInitService workerManagerNodeB = node
+            SCANodeManagerInitService workerManagerNodeB = node
                     .getDomain()
-                    .getService(NodeManagerInitService.class,
+                    .getService(SCANodeManagerInitService.class,
                             "WorkerManagerNodeBComponent/NodeManagerInitService");
             workerManagerNodeB.setNode(node);
         }
 
         if (nodeName.equals("nodeC")) {
-            NodeManagerInitService workerManagerNodeC = node
+            SCANodeManagerInitService workerManagerNodeC = node
                     .getDomain()
-                    .getService(NodeManagerInitService.class,
+                    .getService(SCANodeManagerInitService.class,
                             "WorkerManagerNodeCComponent/NodeManagerInitService");
             workerManagerNodeC.setNode(node);
         }
 
         if (nodeName.equals("nodeD")) {
-            NodeManagerInitService workerManagerNodeD = node
+            SCANodeManagerInitService workerManagerNodeD = node
                     .getDomain()
-                    .getService(NodeManagerInitService.class,
+                    .getService(SCANodeManagerInitService.class,
                             "WorkerManagerNodeDComponent/NodeManagerInitService");
             workerManagerNodeD.setNode(node);
         }
 
         if (nodeName.equals("nodeE")) {
-            NodeManagerInitService workerManagerNodeE = node
+            SCANodeManagerInitService workerManagerNodeE = node
                     .getDomain()
-                    .getService(NodeManagerInitService.class,
+                    .getService(SCANodeManagerInitService.class,
                             "WorkerManagerNodeEComponent/NodeManagerInitService");
             workerManagerNodeE.setNode(node);
         }

Modified: incubator/tuscany/java/sca/demos/workpool-distributed/src/main/java/workpool/WorkerManager.java
URL: http://svn.apache.org/viewvc/incubator/tuscany/java/sca/demos/workpool-distributed/src/main/java/workpool/WorkerManager.java?rev=652371&r1=652370&r2=652371&view=diff
==============================================================================
--- incubator/tuscany/java/sca/demos/workpool-distributed/src/main/java/workpool/WorkerManager.java (original)
+++ incubator/tuscany/java/sca/demos/workpool-distributed/src/main/java/workpool/WorkerManager.java Wed Apr 30 05:38:54 2008
@@ -17,23 +17,15 @@
  * under the License.    
  */
 package workpool;
-
-import org.apache.tuscany.sca.core.context.CallableReferenceImpl;
 import org.osoa.sca.annotations.Remotable;
-
+import org.osoa.sca.CallableReference;
 @Remotable
 public interface WorkerManager {
-    CallableReferenceImpl<WorkerService> addWorker();
-
+    CallableReference<WorkerService> addWorker();
     boolean removeWorker(String workerName);
-
     boolean removeWorkers(int k);
-
     boolean removeAllWorkers();
-
     double getNodeLoad();
-
     int activeWorkers();
-
     void start();
 }

Modified: incubator/tuscany/java/sca/demos/workpool-distributed/src/main/java/workpool/WorkerManagerImpl.java
URL: http://svn.apache.org/viewvc/incubator/tuscany/java/sca/demos/workpool-distributed/src/main/java/workpool/WorkerManagerImpl.java?rev=652371&r1=652370&r2=652371&view=diff
==============================================================================
--- incubator/tuscany/java/sca/demos/workpool-distributed/src/main/java/workpool/WorkerManagerImpl.java (original)
+++ incubator/tuscany/java/sca/demos/workpool-distributed/src/main/java/workpool/WorkerManagerImpl.java Wed Apr 30 05:38:54 2008
@@ -28,12 +28,11 @@
 import org.apache.tuscany.sca.contribution.Contribution;
 import org.apache.tuscany.sca.contribution.DeployedArtifact;
 import org.apache.tuscany.sca.contribution.service.impl.ContributionServiceImpl;
-import org.apache.tuscany.sca.core.context.CallableReferenceImpl;
-import org.apache.tuscany.sca.node.NodeManagerInitService;
+import org.osoa.sca.CallableReference;
+import org.apache.tuscany.sca.node.management.SCANodeManagerInitService;
 import org.apache.tuscany.sca.node.SCANode;
 import org.apache.tuscany.sca.node.impl.SCANodeImpl;
 import org.apache.tuscany.sca.runtime.RuntimeComponent;
-import org.osoa.sca.CallableReference;
 import org.osoa.sca.ComponentContext;
 import org.osoa.sca.annotations.Context;
 import org.osoa.sca.annotations.Property;
@@ -43,10 +42,10 @@
 import java.util.ArrayList;
 
 @Scope("COMPOSITE")
-@Service(interfaces = { NodeManagerInitService.class, WorkerManager.class })
-public class WorkerManagerImpl implements WorkerManager, NodeManagerInitService {
+@Service(interfaces = { SCANodeManagerInitService.class, WorkerManager.class })
+public class WorkerManagerImpl implements WorkerManager, SCANodeManagerInitService {
     private Logger log = Logger.getLogger(WorkerManagerImpl.class.getName());
-    private LinkedList<CallableReferenceImpl<WorkerService>> activeWorkers = new LinkedList<CallableReferenceImpl<WorkerService>>();
+    private LinkedList<CallableReference<WorkerService>> activeWorkers = new LinkedList<CallableReference<WorkerService>>();
     private List<String> workerComponentNames = new ArrayList<String>();
     private SCANodeImpl node;
     @Property
@@ -60,12 +59,11 @@
     private double loadAverage;
 
     /* This method is used to find a composite inside all deployed artifacts */
-    private Composite findComposite(List<DeployedArtifact> artifacts) {
-        for (DeployedArtifact fact : artifacts) {
-            if (fact.getModel() instanceof Composite) {
+    private Composite findComposite(List<Composite> artifacts) {
+        for (Composite fact : artifacts) {
                 log.info("Searching in a contribution deployed artifacts -"
                         + compositeName);
-                Composite augmented = (Composite) fact.getModel();
+                Composite augmented = (Composite) fact;
                 // found
                 if (augmented.getURI().equals(compositeName)) {
                     log.info("Found composite..." + compositeName);
@@ -76,20 +74,18 @@
         return null;
     }
 
-    public CallableReferenceImpl<WorkerService> addWorker() {
+    public CallableReference<WorkerService> addWorker() {
         log.info("Adding a new worker call..");
         long addWorkerStartTime = System.nanoTime();
-        ContributionServiceImpl cServiceImpl = (ContributionServiceImpl) node
-                .getNodeRuntime().getContributionService();
+        ContributionServiceImpl cServiceImpl = (ContributionServiceImpl) node.getContributionService();
         Contribution contribution = cServiceImpl.getContribution(nodeName);
-        List<DeployedArtifact> artifacts = contribution.getArtifacts();
+        List<Composite> artifacts = contribution.getDeployables();
         CallableReference<WorkerService> workerReference = null;
-        CallableReferenceImpl<WorkerService> ref = null;
-        log.info("Instantiating a metacomponent..");
+        CallableReference<WorkerService> ref = null;
+        log.info("Creating a MetaComponentWorker..");
         MetaComponentWorker mcw = new MetaComponentWorker();
         boolean found = false;
         mcw.setWorkerClass(workerClass);
-        // ho trovato la composizione
         Composite augmented = findComposite(artifacts);
         try {
             if (augmented != null) {
@@ -101,15 +97,13 @@
                 RuntimeComponent workerComponent = (RuntimeComponent) node
                         .getComponent(mcw.getName());
                 if (workerComponent != null) {
-                    ref = (CallableReferenceImpl<WorkerService>) workerComponent
+                    ref = (CallableReference<WorkerService>) workerComponent
                             .getComponentContext().createSelfReference(
                                     WorkerService.class);
                     ref.getService().start();
                     activeWorkers.addLast(ref);
                     workerComponentNames.add(mcw.getName());
-                    log.info(context.getURI());
-                    // String name = context.getURI()+"/WorkerManager";
-                    CallableReferenceImpl<WorkerManager> manager = (CallableReferenceImpl) context
+                    CallableReference<WorkerManager> manager = (CallableReference) context
                             .createSelfReference(WorkerManager.class,
                                     "WorkerManager");
                     ref.getService().registerManager(manager);
@@ -129,14 +123,14 @@
     }
 
     public boolean removeAllWorkers() {
-        for (CallableReferenceImpl<WorkerService> callable : activeWorkers) {
+        for (CallableReference<WorkerService> callable : activeWorkers) {
             callable.getService().stop();
         }
         return true;
     }
 
     public boolean removeWorker() {
-        CallableReferenceImpl<WorkerService> callable = activeWorkers
+        CallableReference<WorkerService> callable = activeWorkers
                 .removeLast();
         callable.getService().stop();
         return true;

Modified: incubator/tuscany/java/sca/modules/node-impl/src/main/java/org/apache/tuscany/sca/node/impl/SCANodeImpl.java
URL: http://svn.apache.org/viewvc/incubator/tuscany/java/sca/modules/node-impl/src/main/java/org/apache/tuscany/sca/node/impl/SCANodeImpl.java?rev=652371&r1=652370&r2=652371&view=diff
==============================================================================
--- incubator/tuscany/java/sca/modules/node-impl/src/main/java/org/apache/tuscany/sca/node/impl/SCANodeImpl.java (original)
+++ incubator/tuscany/java/sca/modules/node-impl/src/main/java/org/apache/tuscany/sca/node/impl/SCANodeImpl.java Wed Apr 30 05:38:54 2008
@@ -587,7 +587,20 @@
             }  
         }
     }
-    
+    public ContributionService getContributionService()
+    {
+    	return nodeRuntime.getContributionService();
+    }
+    /* TODO - giorgio:  These are just little steps to support contribution-updater,
+     * 
+     * in order to have more fine grain on updating stuffs.
+    public void addComponentToComposite(MetaComponent mc, String contributionURI, String compositeURI)
+    {
+    }
+    public void removeComponentFromComposite(String nodeName, String compositeURI,String componentName)
+    {
+    }
+    */
     private void activateComposite(Composite composite) throws CompositeBuilderException, ActivationException {
         logger.log(Level.INFO, "Building composite: " + composite.getName());
         

Modified: incubator/tuscany/java/sca/tools/eclipse/features/feature/.project
URL: http://svn.apache.org/viewvc/incubator/tuscany/java/sca/tools/eclipse/features/feature/.project?rev=652371&r1=652370&r2=652371&view=diff
==============================================================================
--- incubator/tuscany/java/sca/tools/eclipse/features/feature/.project (original)
+++ incubator/tuscany/java/sca/tools/eclipse/features/feature/.project Wed Apr 30 05:38:54 2008
@@ -4,23 +4,10 @@
   <projects/>
   <buildSpec>
     <buildCommand>
-      <name>org.eclipse.pde.FeatureBuilder</name>
-    </buildCommand>
-    <buildCommand>
       <name>org.eclipse.jdt.core.javabuilder</name>
     </buildCommand>
-    <buildCommand>
-      <name>org.eclipse.wst.common.project.facet.core.builder</name>
-    </buildCommand>
-    <buildCommand>
-      <name>org.eclipse.wst.validation.validationbuilder</name>
-    </buildCommand>
   </buildSpec>
   <natures>
-    <nature>org.eclipse.pde.FeatureNature</nature>
-    <nature>org.eclipse.wst.common.project.facet.core.nature</nature>
     <nature>org.eclipse.jdt.core.javanature</nature>
-    <nature>org.eclipse.wst.common.modulecore.ModuleCoreNature</nature>
-    <nature>org.eclipse.jem.workbench.JavaEMFNature</nature>
   </natures>
 </projectDescription>
\ No newline at end of file

Modified: incubator/tuscany/java/sca/tools/eclipse/plugins/core/.classpath
URL: http://svn.apache.org/viewvc/incubator/tuscany/java/sca/tools/eclipse/plugins/core/.classpath?rev=652371&r1=652370&r2=652371&view=diff
==============================================================================
--- incubator/tuscany/java/sca/tools/eclipse/plugins/core/.classpath (original)
+++ incubator/tuscany/java/sca/tools/eclipse/plugins/core/.classpath Wed Apr 30 05:38:54 2008
@@ -2,55 +2,55 @@
   <classpathentry kind="src" path="."/>
   <classpathentry kind="output" path="target/classes"/>
   <classpathentry kind="con" path="org.eclipse.jdt.launching.JRE_CONTAINER"/>
-  <classpathentry kind="var" path="M2_REPO/org/eclipse/jdt/debug/ui/3.2.100-v20070531-1800/ui-3.2.100-v20070531-1800.jar"/>
-  <classpathentry kind="var" path="M2_REPO/org/eclipse/ui/ide/3.3.0-I20070531-1800/ide-3.3.0-I20070531-1800.jar"/>
-  <classpathentry kind="var" path="M2_REPO/org/eclipse/core/resources/3.3.0-v20070530/resources-3.3.0-v20070530.jar"/>
-  <classpathentry kind="var" path="M2_REPO/org/eclipse/core/expressions/3.3.0-v20070531-1300/expressions-3.3.0-v20070531-1300.jar"/>
-  <classpathentry kind="var" path="M2_REPO/org/eclipse/core/runtime/3.3.100-v20070530/runtime-3.3.100-v20070530.jar"/>
-  <classpathentry kind="var" path="M2_REPO/org/eclipse/osgi/3.3.0-v20070530/osgi-3.3.0-v20070530.jar"/>
-  <classpathentry kind="var" path="M2_REPO/org/eclipse/equinox/common/3.3.0-v20070426/common-3.3.0-v20070426.jar"/>
-  <classpathentry kind="var" path="M2_REPO/org/eclipse/core/jobs/3.3.0-v20070423/jobs-3.3.0-v20070423.jar"/>
+  <classpathentry kind="var" path="M2_REPO/org/eclipse/core/net/1.0.0-I20070531/net-1.0.0-I20070531.jar"/>
+  <classpathentry kind="var" path="M2_REPO/org/eclipse/update/configurator/3.2.100-v20070507/configurator-3.2.100-v20070507.jar"/>
+  <classpathentry kind="var" path="M2_REPO/org/eclipse/team/ui/3.3.0-I20070524/ui-3.3.0-I20070524.jar"/>
   <classpathentry kind="var" path="M2_REPO/org/eclipse/equinox/registry/3.3.0-v20070522/registry-3.3.0-v20070522.jar"/>
   <classpathentry kind="var" path="M2_REPO/org/eclipse/equinox/preferences/3.2.100-v20070522/preferences-3.2.100-v20070522.jar"/>
-  <classpathentry kind="var" path="M2_REPO/org/eclipse/core/contenttype/3.2.100-v20070319/contenttype-3.2.100-v20070319.jar"/>
-  <classpathentry kind="var" path="M2_REPO/org/eclipse/equinox/app/1.0.0-v20070423/app-1.0.0-v20070423.jar"/>
-  <classpathentry kind="var" path="M2_REPO/org/eclipse/core/filesystem/1.1.0-v20070510/filesystem-1.1.0-v20070510.jar"/>
-  <classpathentry kind="var" path="M2_REPO/org/eclipse/help/3.3.0-v20070524/help-3.3.0-v20070524.jar"/>
-  <classpathentry kind="var" path="M2_REPO/org/eclipse/ui/3.3.0-I20070601-1200/ui-3.3.0-I20070601-1200.jar"/>
-  <classpathentry kind="var" path="M2_REPO/org/eclipse/swt/3.3.0-v3345b/swt-3.3.0-v3345b.jar"/>
+  <classpathentry kind="var" path="M2_REPO/org/eclipse/equinox/common/3.3.0-v20070426/common-3.3.0-v20070426.jar"/>
+  <classpathentry kind="var" path="M2_REPO/org/eclipse/update/core/3.2.100-v20070522/core-3.2.100-v20070522.jar"/>
+  <classpathentry kind="var" path="M2_REPO/org/eclipse/debug/ui/3.3.0-v20070531-1800/ui-3.3.0-v20070531-1800.jar"/>
   <classpathentry kind="var" path="M2_REPO/org/eclipse/jface/3.3.0-I20070601-1200/jface-3.3.0-I20070601-1200.jar"/>
-  <classpathentry kind="var" path="M2_REPO/org/eclipse/core/commands/3.3.0-I20070523-1500/commands-3.3.0-I20070523-1500.jar"/>
-  <classpathentry kind="var" path="M2_REPO/org/eclipse/ui/workbench/3.3.0-I20070601-0010/workbench-3.3.0-I20070601-0010.jar"/>
   <classpathentry kind="var" path="M2_REPO/org/eclipse/jface/databinding/1.1.0-I20070530-0100/databinding-1.1.0-I20070530-0100.jar"/>
-  <classpathentry kind="var" path="M2_REPO/org/eclipse/core/databinding/1.0.0-I20070530-0100/databinding-1.0.0-I20070530-0100.jar"/>
+  <classpathentry kind="var" path="M2_REPO/org/eclipse/ui/navigator/3.3.0-I20070531-1800/navigator-3.3.0-I20070531-1800.jar"/>
   <classpathentry kind="var" path="M2_REPO/org/eclipse/ui/views/3.2.100-I20070319-0010/views-3.2.100-I20070319-0010.jar"/>
-  <classpathentry kind="var" path="M2_REPO/org/eclipse/update/configurator/3.2.100-v20070507/configurator-3.2.100-v20070507.jar"/>
-  <classpathentry kind="var" path="M2_REPO/org/eclipse/update/core/3.2.100-v20070522/core-3.2.100-v20070522.jar"/>
-  <classpathentry kind="var" path="M2_REPO/org/eclipse/core/net/1.0.0-I20070531/net-1.0.0-I20070531.jar"/>
-  <classpathentry kind="var" path="M2_REPO/org/eclipse/update/ui/3.2.100-v20070601a/ui-3.2.100-v20070601a.jar"/>
-  <classpathentry kind="var" path="M2_REPO/org/eclipse/ui/forms/3.3.0-v20070511/forms-3.3.0-v20070511.jar"/>
-  <classpathentry kind="var" path="M2_REPO/org/eclipse/jface/text/3.3.0-v20070531-1300/text-3.3.0-v20070531-1300.jar"/>
-  <classpathentry kind="var" path="M2_REPO/org/eclipse/text/3.3.0-v20070531-1300/text-3.3.0-v20070531-1300.jar"/>
-  <classpathentry kind="var" path="M2_REPO/org/eclipse/ui/workbench/texteditor/3.3.0-v20070531-1300/texteditor-3.3.0-v20070531-1300.jar"/>
-  <classpathentry kind="var" path="M2_REPO/org/eclipse/ui/editors/3.3.0-v20070531-1300/editors-3.3.0-v20070531-1300.jar"/>
-  <classpathentry kind="var" path="M2_REPO/org/eclipse/core/filebuffers/3.3.0-v20070531-1300/filebuffers-3.3.0-v20070531-1300.jar"/>
+  <classpathentry kind="var" path="M2_REPO/org/eclipse/search/3.3.0-v20070531-1300/search-3.3.0-v20070531-1300.jar"/>
+  <classpathentry kind="var" path="M2_REPO/org/eclipse/ltk/core/refactoring/3.3.0-v20070531-1300/refactoring-3.3.0-v20070531-1300.jar"/>
+  <classpathentry kind="var" path="M2_REPO/org/eclipse/core/databinding/1.0.0-I20070530-0100/databinding-1.0.0-I20070530-0100.jar"/>
+  <classpathentry kind="var" path="M2_REPO/org/eclipse/swt/3.3.0-v3345b/swt-3.3.0-v3345b.jar"/>
   <classpathentry kind="var" path="M2_REPO/org/eclipse/core/variables/3.2.0-v20070426/variables-3.2.0-v20070426.jar"/>
+  <classpathentry kind="var" path="M2_REPO/org/eclipse/osgi/3.3.0-v20070530/osgi-3.3.0-v20070530.jar"/>
+  <classpathentry kind="var" path="M2_REPO/org/eclipse/swt/win32/win32/x86/3.3.0-v3346/x86-3.3.0-v3346.jar"/>
+  <classpathentry kind="var" path="M2_REPO/org/eclipse/core/jobs/3.3.0-v20070423/jobs-3.3.0-v20070423.jar"/>
+  <classpathentry kind="var" path="M2_REPO/org/eclipse/core/filesystem/1.1.0-v20070510/filesystem-1.1.0-v20070510.jar"/>
   <classpathentry kind="var" path="M2_REPO/org/eclipse/jdt/core/3.3.0-v_768/core-3.3.0-v_768.jar"/>
-  <classpathentry kind="var" path="M2_REPO/org/eclipse/debug/ui/3.3.0-v20070531-1800/ui-3.3.0-v20070531-1800.jar"/>
-  <classpathentry kind="var" path="M2_REPO/org/eclipse/ui/console/3.2.0-v20070530/console-3.2.0-v20070530.jar"/>
+  <classpathentry kind="var" path="M2_REPO/org/eclipse/team/core/3.2.100-I20070531/core-3.2.100-I20070531.jar"/>
   <classpathentry kind="var" path="M2_REPO/org/eclipse/debug/core/3.3.0-v20070531-1800/core-3.3.0-v20070531-1800.jar"/>
-  <classpathentry kind="var" path="M2_REPO/org/eclipse/jdt/debug/3.3.0-v20070530a/debug-3.3.0-v20070530a.jar"/>
-  <classpathentry kind="var" path="M2_REPO/org/eclipse/jdt/launching/3.3.0-v20070510/launching-3.3.0-v20070510.jar"/>
+  <classpathentry kind="var" path="M2_REPO/org/eclipse/core/resources/3.3.0-v20070530/resources-3.3.0-v20070530.jar"/>
   <classpathentry kind="var" path="M2_REPO/org/eclipse/jdt/ui/3.3.0-v20070531-1300/ui-3.3.0-v20070531-1300.jar"/>
-  <classpathentry kind="var" path="M2_REPO/org/eclipse/search/3.3.0-v20070531-1300/search-3.3.0-v20070531-1300.jar"/>
-  <classpathentry kind="var" path="M2_REPO/org/eclipse/compare/3.3.0-I20070528/compare-3.3.0-I20070528.jar"/>
-  <classpathentry kind="var" path="M2_REPO/org/eclipse/team/ui/3.3.0-I20070524/ui-3.3.0-I20070524.jar"/>
-  <classpathentry kind="var" path="M2_REPO/org/eclipse/team/core/3.2.100-I20070531/core-3.2.100-I20070531.jar"/>
-  <classpathentry kind="var" path="M2_REPO/org/eclipse/ui/navigator/3.3.0-I20070531-1800/navigator-3.3.0-I20070531-1800.jar"/>
+  <classpathentry kind="var" path="M2_REPO/org/eclipse/jdt/launching/3.3.0-v20070510/launching-3.3.0-v20070510.jar"/>
+  <classpathentry kind="var" path="M2_REPO/org/eclipse/ui/workbench/3.3.0-I20070601-0010/workbench-3.3.0-I20070601-0010.jar"/>
+  <classpathentry kind="var" path="M2_REPO/org/eclipse/help/3.3.0-v20070524/help-3.3.0-v20070524.jar"/>
+  <classpathentry kind="var" path="M2_REPO/org/eclipse/equinox/app/1.0.0-v20070423/app-1.0.0-v20070423.jar"/>
+  <classpathentry kind="var" path="M2_REPO/org/eclipse/ui/workbench/texteditor/3.3.0-v20070531-1300/texteditor-3.3.0-v20070531-1300.jar"/>
+  <classpathentry kind="var" path="M2_REPO/org/eclipse/update/ui/3.2.100-v20070601a/ui-3.2.100-v20070601a.jar"/>
+  <classpathentry kind="var" path="M2_REPO/org/eclipse/text/3.3.0-v20070531-1300/text-3.3.0-v20070531-1300.jar"/>
+  <classpathentry kind="var" path="M2_REPO/org/eclipse/core/expressions/3.3.0-v20070531-1300/expressions-3.3.0-v20070531-1300.jar"/>
+  <classpathentry kind="var" path="M2_REPO/org/eclipse/ui/console/3.2.0-v20070530/console-3.2.0-v20070530.jar"/>
   <classpathentry kind="var" path="M2_REPO/org/eclipse/ui/navigator/resources/3.2.100-I20070530-0100/resources-3.2.100-I20070530-0100.jar"/>
+  <classpathentry kind="var" path="M2_REPO/org/eclipse/jdt/debug/ui/3.2.100-v20070531-1800/ui-3.2.100-v20070531-1800.jar"/>
+  <classpathentry kind="var" path="M2_REPO/org/eclipse/compare/3.3.0-I20070528/compare-3.3.0-I20070528.jar"/>
+  <classpathentry kind="var" path="M2_REPO/org/eclipse/core/contenttype/3.2.100-v20070319/contenttype-3.2.100-v20070319.jar"/>
+  <classpathentry kind="var" path="M2_REPO/org/eclipse/core/filebuffers/3.3.0-v20070531-1300/filebuffers-3.3.0-v20070531-1300.jar"/>
   <classpathentry kind="var" path="M2_REPO/org/eclipse/ui/views/properties/tabbed/3.2.100-I20070424-0010/tabbed-3.2.100-I20070424-0010.jar"/>
-  <classpathentry kind="var" path="M2_REPO/org/eclipse/ltk/core/refactoring/3.3.0-v20070531-1300/refactoring-3.3.0-v20070531-1300.jar"/>
-  <classpathentry kind="var" path="M2_REPO/org/eclipse/ltk/ui/refactoring/3.3.0-v20070531-1300/refactoring-3.3.0-v20070531-1300.jar"/>
+  <classpathentry kind="var" path="M2_REPO/org/eclipse/jdt/debug/3.3.0-v20070530a/debug-3.3.0-v20070530a.jar"/>
   <classpathentry kind="var" path="M2_REPO/org/eclipse/jdt/core/manipulation/1.1.0-v20070531-1300/manipulation-1.1.0-v20070531-1300.jar"/>
-  <classpathentry kind="var" path="M2_REPO/org/eclipse/swt/win32/win32/x86/3.3.0-v3346/x86-3.3.0-v3346.jar"/>
+  <classpathentry kind="var" path="M2_REPO/org/eclipse/ui/3.3.0-I20070601-1200/ui-3.3.0-I20070601-1200.jar"/>
+  <classpathentry kind="var" path="M2_REPO/org/eclipse/jface/text/3.3.0-v20070531-1300/text-3.3.0-v20070531-1300.jar"/>
+  <classpathentry kind="var" path="M2_REPO/org/eclipse/ltk/ui/refactoring/3.3.0-v20070531-1300/refactoring-3.3.0-v20070531-1300.jar"/>
+  <classpathentry kind="var" path="M2_REPO/org/eclipse/ui/ide/3.3.0-I20070531-1800/ide-3.3.0-I20070531-1800.jar"/>
+  <classpathentry kind="var" path="M2_REPO/org/eclipse/ui/forms/3.3.0-v20070511/forms-3.3.0-v20070511.jar"/>
+  <classpathentry kind="var" path="M2_REPO/org/eclipse/core/commands/3.3.0-I20070523-1500/commands-3.3.0-I20070523-1500.jar"/>
+  <classpathentry kind="var" path="M2_REPO/org/eclipse/ui/editors/3.3.0-v20070531-1300/editors-3.3.0-v20070531-1300.jar"/>
+  <classpathentry kind="var" path="M2_REPO/org/eclipse/core/runtime/3.3.100-v20070530/runtime-3.3.100-v20070530.jar"/>
 </classpath>
\ No newline at end of file

Modified: incubator/tuscany/java/sca/tools/eclipse/site/updatesite/.project
URL: http://svn.apache.org/viewvc/incubator/tuscany/java/sca/tools/eclipse/site/updatesite/.project?rev=652371&r1=652370&r2=652371&view=diff
==============================================================================
--- incubator/tuscany/java/sca/tools/eclipse/site/updatesite/.project (original)
+++ incubator/tuscany/java/sca/tools/eclipse/site/updatesite/.project Wed Apr 30 05:38:54 2008
@@ -1,17 +1,16 @@
-<?xml version="1.0" encoding="UTF-8"?>
 <projectDescription>
-	<name>org.apache.tuscany.sca.updatesite</name>
-	<comment></comment>
-	<projects>
-	</projects>
-	<buildSpec>
-		<buildCommand>
-			<name>org.eclipse.pde.UpdateSiteBuilder</name>
-			<arguments>
-			</arguments>
-		</buildCommand>
-	</buildSpec>
-	<natures>
-		<nature>org.eclipse.pde.UpdateSiteNature</nature>
-	</natures>
-</projectDescription>
+  <name>org.apache.tuscany.sca.updatesite</name>
+  <comment>Parent POM defining settings that can be used across Tuscany</comment>
+  <projects>
+    <project>org.apache.tuscany.sca.core</project>
+    <project>org.apache.tuscany.sca.feature</project>
+  </projects>
+  <buildSpec>
+    <buildCommand>
+      <name>org.eclipse.jdt.core.javabuilder</name>
+    </buildCommand>
+  </buildSpec>
+  <natures>
+    <nature>org.eclipse.jdt.core.javanature</nature>
+  </natures>
+</projectDescription>
\ No newline at end of file