You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@airavata.apache.org by la...@apache.org on 2012/10/04 22:36:05 UTC

svn commit: r1394252 - in /airavata/trunk/modules/registry/airavata-jpa-registry/src/main/java/org/apache/airavata/persistance/registry/jpa: impl/ resources/

Author: lahiru
Date: Thu Oct  4 20:36:05 2012
New Revision: 1394252

URL: http://svn.apache.org/viewvc?rev=1394252&view=rev
Log:
applying AIRAVATA-594.patch

Added:
    airavata/trunk/modules/registry/airavata-jpa-registry/src/main/java/org/apache/airavata/persistance/registry/jpa/resources/ExperimentDataRetriever.java
Modified:
    airavata/trunk/modules/registry/airavata-jpa-registry/src/main/java/org/apache/airavata/persistance/registry/jpa/impl/AiravataJPARegistry.java
    airavata/trunk/modules/registry/airavata-jpa-registry/src/main/java/org/apache/airavata/persistance/registry/jpa/resources/ExperimentDataResource.java
    airavata/trunk/modules/registry/airavata-jpa-registry/src/main/java/org/apache/airavata/persistance/registry/jpa/resources/GramDataResource.java
    airavata/trunk/modules/registry/airavata-jpa-registry/src/main/java/org/apache/airavata/persistance/registry/jpa/resources/NodeDataResource.java
    airavata/trunk/modules/registry/airavata-jpa-registry/src/main/java/org/apache/airavata/persistance/registry/jpa/resources/WorkflowDataResource.java

Modified: airavata/trunk/modules/registry/airavata-jpa-registry/src/main/java/org/apache/airavata/persistance/registry/jpa/impl/AiravataJPARegistry.java
URL: http://svn.apache.org/viewvc/airavata/trunk/modules/registry/airavata-jpa-registry/src/main/java/org/apache/airavata/persistance/registry/jpa/impl/AiravataJPARegistry.java?rev=1394252&r1=1394251&r2=1394252&view=diff
==============================================================================
--- airavata/trunk/modules/registry/airavata-jpa-registry/src/main/java/org/apache/airavata/persistance/registry/jpa/impl/AiravataJPARegistry.java (original)
+++ airavata/trunk/modules/registry/airavata-jpa-registry/src/main/java/org/apache/airavata/persistance/registry/jpa/impl/AiravataJPARegistry.java Thu Oct  4 20:36:05 2012
@@ -22,7 +22,7 @@ package org.apache.airavata.persistance.
 
 import java.net.URI;
 import java.net.URISyntaxException;
-import java.sql.Timestamp;
+import java.sql.*;
 import java.util.ArrayList;
 import java.util.Calendar;
 import java.util.Date;
@@ -36,21 +36,7 @@ import org.apache.airavata.commons.gfac.
 import org.apache.airavata.commons.gfac.type.ServiceDescription;
 import org.apache.airavata.persistance.registry.jpa.JPAResourceAccessor;
 import org.apache.airavata.persistance.registry.jpa.ResourceUtils;
-import org.apache.airavata.persistance.registry.jpa.resources.ApplicationDescriptorResource;
-import org.apache.airavata.persistance.registry.jpa.resources.ConfigurationResource;
-import org.apache.airavata.persistance.registry.jpa.resources.ExperimentDataResource;
-import org.apache.airavata.persistance.registry.jpa.resources.ExperimentMetadataResource;
-import org.apache.airavata.persistance.registry.jpa.resources.ExperimentResource;
-import org.apache.airavata.persistance.registry.jpa.resources.GatewayResource;
-import org.apache.airavata.persistance.registry.jpa.resources.GramDataResource;
-import org.apache.airavata.persistance.registry.jpa.resources.HostDescriptorResource;
-import org.apache.airavata.persistance.registry.jpa.resources.NodeDataResource;
-import org.apache.airavata.persistance.registry.jpa.resources.ProjectResource;
-import org.apache.airavata.persistance.registry.jpa.resources.PublishWorkflowResource;
-import org.apache.airavata.persistance.registry.jpa.resources.ServiceDescriptorResource;
-import org.apache.airavata.persistance.registry.jpa.resources.UserWorkflowResource;
-import org.apache.airavata.persistance.registry.jpa.resources.WorkerResource;
-import org.apache.airavata.persistance.registry.jpa.resources.WorkflowDataResource;
+import org.apache.airavata.persistance.registry.jpa.resources.*;
 import org.apache.airavata.registry.api.AiravataExperiment;
 import org.apache.airavata.registry.api.AiravataRegistry2;
 import org.apache.airavata.registry.api.AiravataUser;
@@ -72,7 +58,6 @@ import org.apache.airavata.registry.api.
 import org.apache.airavata.registry.api.exception.worker.WorkflowInstanceNodeDoesNotExistsException;
 import org.apache.airavata.registry.api.exception.worker.WorkspaceProjectAlreadyExistsException;
 import org.apache.airavata.registry.api.exception.worker.WorkspaceProjectDoesNotExistsException;
-import org.apache.airavata.registry.api.impl.ExperimentDataImpl;
 import org.apache.airavata.registry.api.workflow.ExperimentData;
 import org.apache.airavata.registry.api.workflow.WorkflowIOData;
 import org.apache.airavata.registry.api.workflow.WorkflowInstance;
@@ -855,8 +840,8 @@ public class AiravataJPARegistry extends
 		if (!isExperimentExists(experimentId)){
 			throw new ExperimentDoesNotExistsException(experimentId);
 		}
-		ExperimentResource experiment = jpa.getWorker().getExperiment(experimentId);
-		return experiment.getData().getExpName();
+        ExperimentDataRetriever experimentDataRetriever = new ExperimentDataRetriever();
+        return experimentDataRetriever.getExperimentName(experimentId, jpa.getWorker().getUser());
 	}
 
 
@@ -1135,33 +1120,17 @@ public class AiravataJPARegistry extends
 		if (!isExperimentExists(experimentId)){
 			throw new ExperimentDoesNotExistsException(experimentId);
 		}
-		ExperimentResource experiment = jpa.getWorker().getExperiment(experimentId);
-		ExperimentDataResource data = experiment.getData();
-		ExperimentData e = new ExperimentDataImpl();
-		e.setExperimentId(experiment.getExpID());
-		e.setExperimentName(data.getExpName());
-		e.setUser(data.getUserName());
-		e.setMetadata(getExperimentMetadata(experimentId));
-		e.setTopic(experiment.getExpID());
-		List<WorkflowInstance> experimentWorkflowInstances = getExperimentWorkflowInstances(experimentId);
-		for (WorkflowInstance workflowInstance : experimentWorkflowInstances) {
-			e.getWorkflowInstanceData().add(getWorkflowInstanceData(workflowInstance.getWorkflowInstanceId()));
-		}
-		return e;
+        ExperimentDataRetriever experimentDataRetriever = new ExperimentDataRetriever();
+        ExperimentData experimentData =  experimentDataRetriever.getExperiment(experimentId);
+        return experimentDataRetriever.getExperiment(experimentId);
 	}
 
 
 	@Override
 	public List<String> getExperimentIdByUser(String user)
 			throws RegistryException {
-		List<String> result=new ArrayList<String>();
-		List<ExperimentResource> experiments = jpa.getWorker().getExperiments();
-		for (ExperimentResource resource : experiments) {
-			if (user==null || resource.getData().getUserName().equals(user)){
-				result.add(resource.getExpID());
-			}
-		}
-		return result;
+        ExperimentDataRetriever experimentDataRetriever = new ExperimentDataRetriever();
+        return experimentDataRetriever.getExperimentIdByUser(jpa.getWorker().getUser());
 	}
 
 
@@ -1285,6 +1254,7 @@ public class AiravataJPARegistry extends
 		}
 		WorkflowDataResource resource = jpa.getWorker().getWorkflowInstance(workflowInstanceId);
 		WorkflowInstance workflowInstance = new WorkflowInstance(resource.getExperimentID(), resource.getWorkflowInstanceID());
+        workflowInstance.setTemplateName(resource.getTemplateName());
 		WorkflowInstanceData workflowInstanceData = new WorkflowInstanceData(null, workflowInstance, new WorkflowInstanceStatus(workflowInstance, resource.getStatus()==null? null:ExecutionStatus.valueOf(resource.getStatus()),resource.getLastUpdatedTime()), null);
 		List<NodeDataResource> nodeData = resource.getNodeData();
 		for (NodeDataResource nodeDataResource : nodeData) {

Modified: airavata/trunk/modules/registry/airavata-jpa-registry/src/main/java/org/apache/airavata/persistance/registry/jpa/resources/ExperimentDataResource.java
URL: http://svn.apache.org/viewvc/airavata/trunk/modules/registry/airavata-jpa-registry/src/main/java/org/apache/airavata/persistance/registry/jpa/resources/ExperimentDataResource.java?rev=1394252&r1=1394251&r2=1394252&view=diff
==============================================================================
--- airavata/trunk/modules/registry/airavata-jpa-registry/src/main/java/org/apache/airavata/persistance/registry/jpa/resources/ExperimentDataResource.java (original)
+++ airavata/trunk/modules/registry/airavata-jpa-registry/src/main/java/org/apache/airavata/persistance/registry/jpa/resources/ExperimentDataResource.java Thu Oct  4 20:36:05 2012
@@ -1,3 +1,24 @@
+/*
+ *
+ * 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.airavata.persistance.registry.jpa.resources;
 
 import org.apache.airavata.persistance.registry.jpa.Resource;

Added: airavata/trunk/modules/registry/airavata-jpa-registry/src/main/java/org/apache/airavata/persistance/registry/jpa/resources/ExperimentDataRetriever.java
URL: http://svn.apache.org/viewvc/airavata/trunk/modules/registry/airavata-jpa-registry/src/main/java/org/apache/airavata/persistance/registry/jpa/resources/ExperimentDataRetriever.java?rev=1394252&view=auto
==============================================================================
--- airavata/trunk/modules/registry/airavata-jpa-registry/src/main/java/org/apache/airavata/persistance/registry/jpa/resources/ExperimentDataRetriever.java (added)
+++ airavata/trunk/modules/registry/airavata-jpa-registry/src/main/java/org/apache/airavata/persistance/registry/jpa/resources/ExperimentDataRetriever.java Thu Oct  4 20:36:05 2012
@@ -0,0 +1,261 @@
+/*
+ *
+ * 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.airavata.persistance.registry.jpa.resources;
+
+import org.apache.airavata.registry.api.impl.ExperimentDataImpl;
+import org.apache.airavata.registry.api.workflow.*;
+import org.apache.airavata.registry.api.workflow.WorkflowInstanceStatus.ExecutionStatus;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
+
+import java.sql.*;
+import java.util.ArrayList;
+import java.util.Date;
+import java.util.List;
+
+public class ExperimentDataRetriever {
+    private static final Logger logger = LoggerFactory.getLogger(ExperimentDataRetriever.class);
+
+    public ExperimentData getExperiment(String experimentId){
+        String connectionURL =  Utils.getJDBCURL();
+        Connection connection = null;
+        ResultSet rs = null;
+        Statement statement;
+        List<WorkflowInstance> experimentWorkflowInstances = new ArrayList<WorkflowInstance>();
+        ExperimentData experimentData = null;
+        try {
+            Class.forName(Utils.getJDBCDriver()).newInstance();
+            connection = DriverManager.getConnection(connectionURL, Utils.getJDBCUser(), Utils.getJDBCPassword());
+            statement = connection.createStatement();
+            String queryString = "SELECT e.experiment_ID, ed.name, e.user_name, em.metadata, " +
+                    "wd.workflow_instanceID, wd.template_name, wd.status, wd.start_time," +
+                    "wd.last_update_time, nd.node_id, nd.inputs, nd.outputs " +
+                    "e.project_name, e.submitted_date, nd.node_type, nd.status," +
+                    "nd.start_time, nd.last_update_time" +
+                    "FROM Experiment e " +
+                    "LEFT JOIN Experiment_Data ed " +
+                    "ON e.experiment_ID = ed.experiment_ID " +
+                    "LEFT JOIN Experiment_Metadata em " +
+                    "ON ed.experiment_ID = em.experiment_ID  " +
+                    "LEFT JOIN Workflow_Data wd " +
+                    "ON e.experiment_ID = wd.experiment_ID " +
+                    "LEFT JOIN Node_Data nd " +
+                    "ON wd.workflow_instanceID = nd.workflow_instanceID " +
+                    "WHERE e.experiment_ID ='" + experimentId + "'";
+
+            rs = statement.executeQuery(queryString);
+            if (rs != null){
+                while (rs.next()) {
+                    experimentData = new ExperimentDataImpl();
+                    experimentData.setExperimentId(rs.getString(1));
+                    experimentData.setExperimentName(rs.getString(2));
+                    experimentData.setUser(rs.getString(3));
+                    experimentData.setMetadata(rs.getString(4));
+                    experimentData.setTopic(rs.getString(1));
+
+                    WorkflowInstance workflowInstance = new WorkflowInstance(experimentId, rs.getString(5));
+                    workflowInstance.setTemplateName(rs.getString(6));
+                    workflowInstance.setExperimentId(rs.getString(1));
+                    workflowInstance.setWorkflowInstanceId(rs.getString(5));
+                    experimentWorkflowInstances.add(workflowInstance);
+
+                    Date lastUpdateDate = new Date(rs.getLong(9));
+                    WorkflowInstanceData workflowInstanceData = new WorkflowInstanceData(null,
+                            workflowInstance, new WorkflowInstanceStatus(workflowInstance,
+                            rs.getString(7)==null? null:ExecutionStatus.valueOf(rs.getString(7)),lastUpdateDate), null);
+                    workflowInstanceData.setExperimentData(experimentData);
+
+                    WorkflowInstanceNode workflowInstanceNode = new WorkflowInstanceNode(workflowInstance, rs.getString(10));
+
+                    WorkflowInstanceNodeData workflowInstanceNodeData = new WorkflowInstanceNodeData(workflowInstanceNode);
+                    workflowInstanceNodeData.setInput(rs.getString(11));
+                    workflowInstanceNodeData.setOutput(rs.getString(12));
+
+                    workflowInstanceData.getNodeDataList().add(workflowInstanceNodeData);
+                    experimentData.getWorkflowInstanceData().add(workflowInstanceData);
+                }
+            }
+            rs.close();
+            statement.close();
+            connection.close();
+        } catch (InstantiationException e) {
+            e.printStackTrace();
+            logger.error(e.getMessage(), e);
+        } catch (IllegalAccessException e) {
+            e.printStackTrace();
+            logger.error(e.getMessage(), e);
+        } catch (ClassNotFoundException e) {
+            e.printStackTrace();
+            logger.error(e.getMessage(), e);
+        } catch (SQLException e){
+            e.printStackTrace();
+        }
+        return experimentData;
+    }
+
+    public List<String> getExperimentIdByUser(String user){
+        List<String> result=new ArrayList<String>();
+        String connectionURL =  Utils.getJDBCURL();
+        Connection connection = null;
+        ResultSet rs = null;
+        Statement statement = null;
+        try {
+            String jdbcDriver =  Utils.getJDBCDriver();
+            Class.forName(jdbcDriver).newInstance();
+            connection = DriverManager.getConnection(connectionURL, Utils.getJDBCUser(), Utils.getJDBCPassword());
+            statement = connection.createStatement();
+
+            String queryString = "SELECT experiment_ID FROM Experiment WHERE user_name ='" +  user + "'";
+            rs = statement.executeQuery(queryString);
+            if(rs != null){
+                while (rs.next()) {
+                    result.add(rs.getString(1));
+                }
+            }
+            rs.close();
+            statement.close();
+            connection.close();
+        } catch (InstantiationException e) {
+            e.printStackTrace();
+            logger.error(e.getMessage(), e);
+        } catch (IllegalAccessException e) {
+            e.printStackTrace();
+            logger.error(e.getMessage(), e);
+        } catch (ClassNotFoundException e) {
+            e.printStackTrace();
+            logger.error(e.getMessage(), e);
+        } catch (SQLException e){
+            e.printStackTrace();
+        }
+
+        return result;
+
+    }
+
+    public String getExperimentName(String experimentId, String user){
+        String connectionURL =  Utils.getJDBCURL();
+        Connection connection;
+        Statement statement;
+        ResultSet rs;
+        try {
+            Class.forName(Utils.getJDBCDriver()).newInstance();
+            connection = DriverManager.getConnection(connectionURL, Utils.getJDBCUser(), Utils.getJDBCPassword());
+            statement =  connection.createStatement();
+            String queryString = "SELECT ed.name FROM Experiment e " +
+                    "LEFT JOIN Experiment_Data ed " +
+                    "ON e.experiment_ID = ed.experiment_ID " +
+                    "WHERE e.user_name ='" +  user +
+                    "' AND e.experiment_ID='" + experimentId + "'";
+            rs = statement.executeQuery(queryString);
+            if(rs != null){
+                while (rs.next()) {
+                    return rs.getString(1);
+                }
+            }
+            rs.close();
+            statement.close();
+            connection.close();
+        } catch (InstantiationException e) {
+            logger.error(e.getMessage(), e);
+        } catch (IllegalAccessException e) {
+            logger.error(e.getMessage(), e);
+        } catch (ClassNotFoundException e) {
+            logger.error(e.getMessage(), e);
+        } catch (SQLException e){
+            logger.error(e.getMessage(), e);
+        }
+        return null;
+    }
+
+    public List<ExperimentData> getExperiments(){
+        List<ExperimentData> experimentDataList = new ArrayList<ExperimentData>();
+        String connectionURL =  Utils.getJDBCURL();
+        Connection connection = null;
+        ResultSet rs = null;
+        Statement statement;
+        List<WorkflowInstance> experimentWorkflowInstances = new ArrayList<WorkflowInstance>();
+        ExperimentData experimentData;
+        try {
+            Class.forName(Utils.getJDBCDriver()).newInstance();
+            connection = DriverManager.getConnection(connectionURL, Utils.getJDBCUser(),
+                    Utils.getJDBCPassword());
+            statement = connection.createStatement();
+            String queryString = "SELECT e.experiment_ID, ed.name, e.user_name, em.metadata, " +
+                    "wd.workflow_instanceID, wd.template_name, wd.status, wd.start_time," +
+                    "wd.last_update_time, nd.node_id, nd.inputs, nd.outputs, " +
+                    "e.project_name, e.submitted_date, nd.node_type, nd.status," +
+                    "nd.start_time, nd.last_update_time" +
+                    " FROM Experiment e INNER JOIN Experiment_Data ed " +
+                    "ON e.experiment_ID = ed.experiment_ID " +
+                    "LEFT JOIN Experiment_Metadata em " +
+                    "ON ed.experiment_ID = em.experiment_ID  " +
+                    "LEFT JOIN Workflow_Data wd " +
+                    "ON e.experiment_ID = wd.experiment_ID " +
+                    "LEFT JOIN Node_Data nd " +
+                    "ON wd.workflow_instanceID = nd.workflow_instanceID'";
+
+            rs = statement.executeQuery(queryString);
+            while (rs.next()) {
+                experimentData = new ExperimentDataImpl();
+                experimentData.setExperimentId(rs.getString(1));
+                experimentData.setExperimentName(rs.getString(2));
+                experimentData.setUser(rs.getString(3));
+                experimentData.setMetadata(rs.getString(4));
+                experimentData.setTopic(rs.getString(1));
+
+                WorkflowInstance workflowInstance = new WorkflowInstance(rs.getString(1), rs.getString(5));
+                workflowInstance.setTemplateName(rs.getString(6));
+                workflowInstance.setExperimentId(rs.getString(1));
+                workflowInstance.setWorkflowInstanceId(rs.getString(5));
+                experimentWorkflowInstances.add(workflowInstance);
+
+                Date lastUpdateDate = new Date(rs.getLong(9));
+                WorkflowInstanceData workflowInstanceData = new WorkflowInstanceData(null,
+                        workflowInstance, new WorkflowInstanceStatus(workflowInstance,
+                        rs.getString(7)==null? null: WorkflowInstanceStatus.ExecutionStatus.valueOf(rs.getString(7)),lastUpdateDate), null);
+                workflowInstanceData.setExperimentData(experimentData);
+
+                WorkflowInstanceNode workflowInstanceNode = new WorkflowInstanceNode(workflowInstance, rs.getString(10));
+
+                WorkflowInstanceNodeData workflowInstanceNodeData = new WorkflowInstanceNodeData(workflowInstanceNode);
+                workflowInstanceNodeData.setInput(rs.getString(11));
+                workflowInstanceNodeData.setOutput(rs.getString(12));
+
+                workflowInstanceData.getNodeDataList().add(workflowInstanceNodeData);
+                experimentData.getWorkflowInstanceData().add(workflowInstanceData);
+                experimentDataList.add(experimentData);
+            }
+            rs.close();
+            statement.close();
+            connection.close();
+        } catch (InstantiationException e) {
+            logger.error(e.getMessage(), e);
+        } catch (IllegalAccessException e) {
+            logger.error(e.getMessage(), e);
+        } catch (ClassNotFoundException e) {
+            logger.error(e.getMessage(), e);
+        } catch (SQLException e){
+            e.printStackTrace();
+        }
+        return experimentDataList;
+    }
+}

Modified: airavata/trunk/modules/registry/airavata-jpa-registry/src/main/java/org/apache/airavata/persistance/registry/jpa/resources/GramDataResource.java
URL: http://svn.apache.org/viewvc/airavata/trunk/modules/registry/airavata-jpa-registry/src/main/java/org/apache/airavata/persistance/registry/jpa/resources/GramDataResource.java?rev=1394252&r1=1394251&r2=1394252&view=diff
==============================================================================
--- airavata/trunk/modules/registry/airavata-jpa-registry/src/main/java/org/apache/airavata/persistance/registry/jpa/resources/GramDataResource.java (original)
+++ airavata/trunk/modules/registry/airavata-jpa-registry/src/main/java/org/apache/airavata/persistance/registry/jpa/resources/GramDataResource.java Thu Oct  4 20:36:05 2012
@@ -1,3 +1,24 @@
+/*
+ *
+ * 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.airavata.persistance.registry.jpa.resources;
 
 

Modified: airavata/trunk/modules/registry/airavata-jpa-registry/src/main/java/org/apache/airavata/persistance/registry/jpa/resources/NodeDataResource.java
URL: http://svn.apache.org/viewvc/airavata/trunk/modules/registry/airavata-jpa-registry/src/main/java/org/apache/airavata/persistance/registry/jpa/resources/NodeDataResource.java?rev=1394252&r1=1394251&r2=1394252&view=diff
==============================================================================
--- airavata/trunk/modules/registry/airavata-jpa-registry/src/main/java/org/apache/airavata/persistance/registry/jpa/resources/NodeDataResource.java (original)
+++ airavata/trunk/modules/registry/airavata-jpa-registry/src/main/java/org/apache/airavata/persistance/registry/jpa/resources/NodeDataResource.java Thu Oct  4 20:36:05 2012
@@ -1,3 +1,24 @@
+/*
+ *
+ * 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.airavata.persistance.registry.jpa.resources;
 
 

Modified: airavata/trunk/modules/registry/airavata-jpa-registry/src/main/java/org/apache/airavata/persistance/registry/jpa/resources/WorkflowDataResource.java
URL: http://svn.apache.org/viewvc/airavata/trunk/modules/registry/airavata-jpa-registry/src/main/java/org/apache/airavata/persistance/registry/jpa/resources/WorkflowDataResource.java?rev=1394252&r1=1394251&r2=1394252&view=diff
==============================================================================
--- airavata/trunk/modules/registry/airavata-jpa-registry/src/main/java/org/apache/airavata/persistance/registry/jpa/resources/WorkflowDataResource.java (original)
+++ airavata/trunk/modules/registry/airavata-jpa-registry/src/main/java/org/apache/airavata/persistance/registry/jpa/resources/WorkflowDataResource.java Thu Oct  4 20:36:05 2012
@@ -1,3 +1,24 @@
+/*
+ *
+ * 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.airavata.persistance.registry.jpa.resources;
 
 import org.apache.airavata.persistance.registry.jpa.Resource;