You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@airavata.apache.org by ra...@apache.org on 2014/05/06 17:39:57 UTC

[1/2] git commit: Changed the thrift model. AIRAVATA-1199

Repository: airavata
Updated Branches:
  refs/heads/master c11651bc5 -> 04269ff81


Changed the thrift model. AIRAVATA-1199

Project: http://git-wip-us.apache.org/repos/asf/airavata/repo
Commit: http://git-wip-us.apache.org/repos/asf/airavata/commit/70846f38
Tree: http://git-wip-us.apache.org/repos/asf/airavata/tree/70846f38
Diff: http://git-wip-us.apache.org/repos/asf/airavata/diff/70846f38

Branch: refs/heads/master
Commit: 70846f388c1af98bacbc1ddb6c937ba35d874045
Parents: c11651b
Author: raminder <ra...@apache.org>
Authored: Tue May 6 11:32:11 2014 -0400
Committer: raminder <ra...@apache.org>
Committed: Tue May 6 11:32:11 2014 -0400

----------------------------------------------------------------------
 .../experimentModel.thrift                          | 16 +++++++++++++++-
 1 file changed, 15 insertions(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/airavata/blob/70846f38/airavata-api/thrift-interface-descriptions/experimentModel.thrift
----------------------------------------------------------------------
diff --git a/airavata-api/thrift-interface-descriptions/experimentModel.thrift b/airavata-api/thrift-interface-descriptions/experimentModel.thrift
index f01ae7d..bb627ae 100644
--- a/airavata-api/thrift-interface-descriptions/experimentModel.thrift
+++ b/airavata-api/thrift-interface-descriptions/experimentModel.thrift
@@ -178,6 +178,20 @@ enum CorrectiveAction {
     CANNOT_BE_DETERMINED
 }
 
+enum CorrectiveAction {
+    RETRY_SUBMISSION,
+    CONTACT_SUPPORT,
+    CANNOT_BE_DETERMINED
+}
+
+enum DataType{
+	STRING,
+	INTEGER,
+	URI,
+	STDOUT,
+	STDERR
+}
+
 /**
 * A structure  hold experiment input output
 *
@@ -185,7 +199,7 @@ enum CorrectiveAction {
 struct DataObjectType {
     1: required string key,
     2: optional string value,
-    3: optional string type,
+    3: optional DataType type,
     4: optional string metaData
 }
 


[2/2] git commit: Changed the Registry DataType to RegistryModelType. AIRAVATA-1199

Posted by ra...@apache.org.
Changed the Registry DataType to RegistryModelType. AIRAVATA-1199

Project: http://git-wip-us.apache.org/repos/asf/airavata/repo
Commit: http://git-wip-us.apache.org/repos/asf/airavata/commit/04269ff8
Tree: http://git-wip-us.apache.org/repos/asf/airavata/tree/04269ff8
Diff: http://git-wip-us.apache.org/repos/asf/airavata/diff/04269ff8

Branch: refs/heads/master
Commit: 04269ff81f40b50198aea00b7b919d789625e18a
Parents: 70846f3
Author: raminder <ra...@apache.org>
Authored: Tue May 6 11:39:33 2014 -0400
Committer: raminder <ra...@apache.org>
Committed: Tue May 6 11:39:33 2014 -0400

----------------------------------------------------------------------
 .../server/handler/AiravataServerHandler.java   | 28 ++++++-------
 .../apache/airavata/gfac/core/cpi/GFacImpl.java |  6 +--
 .../AiravataExperimentStatusUpdator.java        |  6 +--
 .../core/monitor/AiravataJobStatusUpdator.java  |  6 +--
 .../core/monitor/AiravataTaskStatusUpdator.java |  6 +--
 .../AiravataWorkflowNodeStatusUpdator.java      |  6 +--
 .../airavata/gfac/core/utils/GFacUtils.java     |  2 +-
 .../gsissh/handler/GSISSHOutputHandler.java     |  4 +-
 .../gfac/ssh/handler/SSHOutputHandler.java      |  4 +-
 .../server/OrchestratorServerHandler.java       | 10 ++---
 .../validator/impl/SimpleAppDataValidator.java  |  2 +-
 .../cpi/impl/SimpleOrchestratorImpl.java        |  4 +-
 .../registry/jpa/impl/ExperimentRegistry.java   | 42 ++++++++++----------
 .../registry/jpa/impl/LoggingRegistryImpl.java  | 16 ++++----
 .../registry/jpa/impl/RegistryImpl.java         | 16 ++++----
 .../apache/airavata/registry/cpi/DataType.java  | 31 ---------------
 .../apache/airavata/registry/cpi/Registry.java  | 16 ++++----
 .../registry/cpi/RegistryModelType.java         | 31 +++++++++++++++
 18 files changed, 118 insertions(+), 118 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/airavata/blob/04269ff8/airavata-api/airavata-api-server/src/main/java/org/apache/airavata/api/server/handler/AiravataServerHandler.java
----------------------------------------------------------------------
diff --git a/airavata-api/airavata-api-server/src/main/java/org/apache/airavata/api/server/handler/AiravataServerHandler.java b/airavata-api/airavata-api-server/src/main/java/org/apache/airavata/api/server/handler/AiravataServerHandler.java
index 609cf12..a8f3396 100644
--- a/airavata-api/airavata-api-server/src/main/java/org/apache/airavata/api/server/handler/AiravataServerHandler.java
+++ b/airavata-api/airavata-api-server/src/main/java/org/apache/airavata/api/server/handler/AiravataServerHandler.java
@@ -85,7 +85,7 @@ public class AiravataServerHandler implements Airavata.Iface {
     public void updateProject(Project project) throws InvalidRequestException, AiravataClientException, AiravataSystemException, TException {
         try {
             registry = RegistryFactory.getDefaultRegistry();
-            registry.update(DataType.PROJECT, project, project.getProjectID());
+            registry.update(RegistryModelType.PROJECT, project, project.getProjectID());
         } catch (RegistryException e) {
             logger.error("Error while updating the project", e);
             throw new AiravataSystemException(AiravataErrorType.INTERNAL_ERROR);
@@ -101,7 +101,7 @@ public class AiravataServerHandler implements Airavata.Iface {
     public Project getProject(String projectId) throws InvalidRequestException, AiravataClientException, AiravataSystemException, TException {
         try {
             registry = RegistryFactory.getDefaultRegistry();
-            return (Project)registry.get(DataType.PROJECT, projectId);
+            return (Project)registry.get(RegistryModelType.PROJECT, projectId);
         } catch (RegistryException e) {
             logger.error("Error while updating the project", e);
             throw new AiravataSystemException(AiravataErrorType.INTERNAL_ERROR);
@@ -118,7 +118,7 @@ public class AiravataServerHandler implements Airavata.Iface {
         List<Project> projects = new ArrayList<Project>();
         try {
             registry = RegistryFactory.getDefaultRegistry();
-            List<Object> list = registry.get(DataType.PROJECT, Constants.FieldConstants.ProjectConstants.OWNER, userName);
+            List<Object> list = registry.get(RegistryModelType.PROJECT, Constants.FieldConstants.ProjectConstants.OWNER, userName);
             if (list != null && !list.isEmpty()){
                 for (Object o : list){
                     projects.add((Project) o);
@@ -141,8 +141,8 @@ public class AiravataServerHandler implements Airavata.Iface {
         try {
             List<Experiment> experiments = new ArrayList<Experiment>();
             registry = RegistryFactory.getDefaultRegistry();
-            if (registry.isExist(DataType.PROJECT, projectId)){
-	            List<Object> list = registry.get(DataType.EXPERIMENT, Constants.FieldConstants.ExperimentConstants.PROJECT_NAME, projectId);
+            if (registry.isExist(RegistryModelType.PROJECT, projectId)){
+	            List<Object> list = registry.get(RegistryModelType.EXPERIMENT, Constants.FieldConstants.ExperimentConstants.PROJECT_NAME, projectId);
 	            if (list != null && !list.isEmpty()){
 	                for (Object o : list){
 	                    experiments.add((Experiment)o);
@@ -166,7 +166,7 @@ public class AiravataServerHandler implements Airavata.Iface {
         try {
             List<Experiment> experiments = new ArrayList<Experiment>();
             registry = RegistryFactory.getDefaultRegistry();
-            List<Object> list = registry.get(DataType.EXPERIMENT, Constants.FieldConstants.ExperimentConstants.USER_NAME, userName);
+            List<Object> list = registry.get(RegistryModelType.EXPERIMENT, Constants.FieldConstants.ExperimentConstants.USER_NAME, userName);
             if (list != null && !list.isEmpty()){
                 for (Object o : list){
                     experiments.add((Experiment)o);
@@ -238,7 +238,7 @@ public class AiravataServerHandler implements Airavata.Iface {
     public Experiment getExperiment(String airavataExperimentId) throws InvalidRequestException, ExperimentNotFoundException, AiravataClientException, AiravataSystemException, TException {
         try {
             registry = RegistryFactory.getDefaultRegistry();
-            return (Experiment)registry.get(DataType.EXPERIMENT, airavataExperimentId);
+            return (Experiment)registry.get(RegistryModelType.EXPERIMENT, airavataExperimentId);
         } catch (Exception e) {
             logger.error("Error while retrieving the experiment", e);
             throw new AiravataSystemException(AiravataErrorType.INTERNAL_ERROR);
@@ -274,7 +274,7 @@ public class AiravataServerHandler implements Airavata.Iface {
     public void updateExperiment(String airavataExperimentId, Experiment experiment) throws InvalidRequestException, ExperimentNotFoundException, AiravataClientException, AiravataSystemException, TException {
         try {
             registry = RegistryFactory.getDefaultRegistry();
-            registry.update(DataType.EXPERIMENT, experiment, airavataExperimentId);
+            registry.update(RegistryModelType.EXPERIMENT, experiment, airavataExperimentId);
         } catch (Exception e) {
             logger.error("Error while updating experiment", e);
             throw new AiravataSystemException(AiravataErrorType.INTERNAL_ERROR);
@@ -328,7 +328,7 @@ public class AiravataServerHandler implements Airavata.Iface {
     public ExperimentStatus getExperimentStatus(String airavataExperimentId) throws InvalidRequestException, ExperimentNotFoundException, AiravataClientException, AiravataSystemException, TException {
         try {
             registry = RegistryFactory.getDefaultRegistry();
-            return (ExperimentStatus)registry.get(DataType.EXPERIMENT_STATUS, airavataExperimentId);
+            return (ExperimentStatus)registry.get(RegistryModelType.EXPERIMENT_STATUS, airavataExperimentId);
         } catch (Exception e) {
             logger.error("Error while retrieving the experiment status", e);
             throw new AiravataSystemException(AiravataErrorType.INTERNAL_ERROR);
@@ -339,7 +339,7 @@ public class AiravataServerHandler implements Airavata.Iface {
     public List<DataObjectType> getExperimentOutputs(String airavataExperimentId) throws TException {
         try {
             registry = RegistryFactory.getDefaultRegistry();
-            return (List<DataObjectType>)registry.get(DataType.EXPERIMENT_OUTPUT, airavataExperimentId);
+            return (List<DataObjectType>)registry.get(RegistryModelType.EXPERIMENT_OUTPUT, airavataExperimentId);
         } catch (Exception e) {
             logger.error("Error while retrieving the experiment outputs", e);
             throw new AiravataSystemException(AiravataErrorType.INTERNAL_ERROR);
@@ -350,15 +350,15 @@ public class AiravataServerHandler implements Airavata.Iface {
         Map<String, JobStatus> jobStatus = new HashMap<String, JobStatus>();
         try {
             registry = RegistryFactory.getDefaultRegistry();
-            List<Object> workflowNodes = registry.get(DataType.WORKFLOW_NODE_DETAIL, Constants.FieldConstants.WorkflowNodeConstants.EXPERIMENT_ID, airavataExperimentId);
+            List<Object> workflowNodes = registry.get(RegistryModelType.WORKFLOW_NODE_DETAIL, Constants.FieldConstants.WorkflowNodeConstants.EXPERIMENT_ID, airavataExperimentId);
             if (workflowNodes != null && !workflowNodes.isEmpty()){
                 for (Object wf : workflowNodes){
                     String nodeInstanceId = ((WorkflowNodeDetails) wf).getNodeInstanceId();
-                    List<Object> taskDetails = registry.get(DataType.TASK_DETAIL, Constants.FieldConstants.TaskDetailConstants.NODE_ID, nodeInstanceId);
+                    List<Object> taskDetails = registry.get(RegistryModelType.TASK_DETAIL, Constants.FieldConstants.TaskDetailConstants.NODE_ID, nodeInstanceId);
                     if (taskDetails != null && !taskDetails.isEmpty()){
                         for (Object ts : taskDetails){
                             String taskID = ((TaskDetails) ts).getTaskID();
-                            List<Object> jobDetails = registry.get(DataType.JOB_DETAIL, Constants.FieldConstants.JobDetaisConstants.TASK_ID, taskID);
+                            List<Object> jobDetails = registry.get(RegistryModelType.JOB_DETAIL, Constants.FieldConstants.JobDetaisConstants.TASK_ID, taskID);
                             if (jobDetails != null && !jobDetails.isEmpty()){
                                 for (Object job : jobDetails){
                                     String jobID = ((JobDetails) job).getJobID();
@@ -459,7 +459,7 @@ public class AiravataServerHandler implements Airavata.Iface {
     public String cloneExperiment(String airavataExperimentIdToBeCloned, Experiment updatedExperiment) throws InvalidRequestException, ExperimentNotFoundException, AiravataClientException, AiravataSystemException, TException {
         try {
             registry = RegistryFactory.getDefaultRegistry();
-            UserConfigurationData previousConfiguration = (UserConfigurationData)registry.get(DataType.EXPERIMENT_CONFIGURATION_DATA, updatedExperiment.getExperimentID());
+            UserConfigurationData previousConfiguration = (UserConfigurationData)registry.get(RegistryModelType.EXPERIMENT_CONFIGURATION_DATA, updatedExperiment.getExperimentID());
             updatedExperiment.setUserConfigurationData(previousConfiguration);
             updatedExperiment.setName(airavataExperimentIdToBeCloned);
             return (String)registry.add(ParentDataType.EXPERIMENT, updatedExperiment);

http://git-wip-us.apache.org/repos/asf/airavata/blob/04269ff8/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/cpi/GFacImpl.java
----------------------------------------------------------------------
diff --git a/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/cpi/GFacImpl.java b/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/cpi/GFacImpl.java
index 1d5c6f9..ef988b0 100644
--- a/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/cpi/GFacImpl.java
+++ b/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/cpi/GFacImpl.java
@@ -58,7 +58,7 @@ import org.apache.airavata.model.workspace.experiment.DataObjectType;
 import org.apache.airavata.model.workspace.experiment.Experiment;
 import org.apache.airavata.model.workspace.experiment.TaskDetails;
 import org.apache.airavata.registry.api.AiravataRegistry2;
-import org.apache.airavata.registry.cpi.DataType;
+import org.apache.airavata.registry.cpi.RegistryModelType;
 import org.apache.airavata.registry.cpi.Registry;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
@@ -201,7 +201,7 @@ public class GFacImpl implements GFac {
 
     private JobExecutionContext createJEC(String experimentID, String taskID) throws Exception {
         JobExecutionContext jobExecutionContext;
-        TaskDetails taskData = (TaskDetails) registry.get(DataType.TASK_DETAIL, taskID);
+        TaskDetails taskData = (TaskDetails) registry.get(RegistryModelType.TASK_DETAIL, taskID);
 
         // this is wear our new model and old model is mapping (so serviceName in ExperimentData and service name in ServiceDescriptor
         // has to be same.
@@ -239,7 +239,7 @@ public class GFacImpl implements GFac {
         jobExecutionContext = new JobExecutionContext(gFacConfiguration, serviceName);
 
         // setting experiment/task/workflownode related information
-        Experiment experiment = (Experiment) registry.get(DataType.EXPERIMENT, experimentID);
+        Experiment experiment = (Experiment) registry.get(RegistryModelType.EXPERIMENT, experimentID);
         jobExecutionContext.setExperiment(experiment);
         jobExecutionContext.setExperimentID(experimentID);
         jobExecutionContext.setWorkflowNodeDetails(experiment.getWorkflowNodeDetailsList().get(0));

http://git-wip-us.apache.org/repos/asf/airavata/blob/04269ff8/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/monitor/AiravataExperimentStatusUpdator.java
----------------------------------------------------------------------
diff --git a/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/monitor/AiravataExperimentStatusUpdator.java b/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/monitor/AiravataExperimentStatusUpdator.java
index f265503..e2064cf 100644
--- a/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/monitor/AiravataExperimentStatusUpdator.java
+++ b/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/monitor/AiravataExperimentStatusUpdator.java
@@ -24,7 +24,7 @@ import com.google.common.eventbus.Subscribe;
 import org.apache.airavata.gfac.core.monitor.state.ExperimentStatusChangeRequest;
 import org.apache.airavata.model.workspace.experiment.Experiment;
 import org.apache.airavata.model.workspace.experiment.ExperimentState;
-import org.apache.airavata.registry.cpi.DataType;
+import org.apache.airavata.registry.cpi.RegistryModelType;
 import org.apache.airavata.registry.cpi.Registry;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
@@ -58,7 +58,7 @@ public class AiravataExperimentStatusUpdator implements AbstractActivityListener
     }
 
     public  void updateExperimentStatus(String experimentId, ExperimentState state) throws Exception {
-    	Experiment details = (Experiment)airavataRegistry.get(DataType.EXPERIMENT, experimentId);
+    	Experiment details = (Experiment)airavataRegistry.get(RegistryModelType.EXPERIMENT, experimentId);
         if(details == null) {
             details = new Experiment();
             details.setExperimentID(experimentId);
@@ -67,7 +67,7 @@ public class AiravataExperimentStatusUpdator implements AbstractActivityListener
         status.setExperimentState(state);
         status.setTimeOfStateChange(Calendar.getInstance().getTimeInMillis());
         details.setExperimentStatus(status);
-        airavataRegistry.update(DataType.EXPERIMENT, details, experimentId);
+        airavataRegistry.update(RegistryModelType.EXPERIMENT, details, experimentId);
     }
 
 	public void setup(Object... configurations) {

http://git-wip-us.apache.org/repos/asf/airavata/blob/04269ff8/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/monitor/AiravataJobStatusUpdator.java
----------------------------------------------------------------------
diff --git a/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/monitor/AiravataJobStatusUpdator.java b/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/monitor/AiravataJobStatusUpdator.java
index 254d7fc..29ee82f 100644
--- a/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/monitor/AiravataJobStatusUpdator.java
+++ b/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/monitor/AiravataJobStatusUpdator.java
@@ -28,7 +28,7 @@ import org.apache.airavata.model.workspace.experiment.JobDetails;
 import org.apache.airavata.model.workspace.experiment.JobState;
 import org.apache.airavata.model.workspace.experiment.TaskState;
 import org.apache.airavata.registry.cpi.CompositeIdentifier;
-import org.apache.airavata.registry.cpi.DataType;
+import org.apache.airavata.registry.cpi.RegistryModelType;
 import org.apache.airavata.registry.cpi.Registry;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
@@ -102,7 +102,7 @@ public class AiravataJobStatusUpdator implements AbstractActivityListener {
 
     public  void updateJobStatus(String taskId, String jobID, JobState state) throws Exception {
         CompositeIdentifier ids = new CompositeIdentifier(taskId, jobID);
-        JobDetails details = (JobDetails)airavataRegistry.get(DataType.JOB_DETAIL, ids);
+        JobDetails details = (JobDetails)airavataRegistry.get(RegistryModelType.JOB_DETAIL, ids);
         if(details == null) {
             details = new JobDetails();
         }
@@ -111,7 +111,7 @@ public class AiravataJobStatusUpdator implements AbstractActivityListener {
         status.setTimeOfStateChange(Calendar.getInstance().getTimeInMillis());
         details.setJobStatus(status);
         details.setJobID(jobID);
-        airavataRegistry.update(DataType.JOB_DETAIL, details, ids);
+        airavataRegistry.update(RegistryModelType.JOB_DETAIL, details, ids);
     }
 
 	@SuppressWarnings("unchecked")

http://git-wip-us.apache.org/repos/asf/airavata/blob/04269ff8/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/monitor/AiravataTaskStatusUpdator.java
----------------------------------------------------------------------
diff --git a/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/monitor/AiravataTaskStatusUpdator.java b/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/monitor/AiravataTaskStatusUpdator.java
index 8a57571..a6ab613 100644
--- a/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/monitor/AiravataTaskStatusUpdator.java
+++ b/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/monitor/AiravataTaskStatusUpdator.java
@@ -27,7 +27,7 @@ import org.apache.airavata.gfac.core.notification.MonitorPublisher;
 import org.apache.airavata.model.workspace.experiment.TaskDetails;
 import org.apache.airavata.model.workspace.experiment.TaskState;
 import org.apache.airavata.model.workspace.experiment.WorkflowNodeState;
-import org.apache.airavata.registry.cpi.DataType;
+import org.apache.airavata.registry.cpi.RegistryModelType;
 import org.apache.airavata.registry.cpi.Registry;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
@@ -88,7 +88,7 @@ public class AiravataTaskStatusUpdator implements AbstractActivityListener {
     }
     
     public  void updateTaskStatus(String taskId, TaskState state) throws Exception {
-    	TaskDetails details = (TaskDetails)airavataRegistry.get(DataType.TASK_DETAIL, taskId);
+    	TaskDetails details = (TaskDetails)airavataRegistry.get(RegistryModelType.TASK_DETAIL, taskId);
         if(details == null) {
             details = new TaskDetails();
             details.setTaskID(taskId);
@@ -97,7 +97,7 @@ public class AiravataTaskStatusUpdator implements AbstractActivityListener {
         status.setExecutionState(state);
         status.setTimeOfStateChange(Calendar.getInstance().getTimeInMillis());
         details.setTaskStatus(status);
-        airavataRegistry.update(DataType.TASK_DETAIL, details, taskId);
+        airavataRegistry.update(RegistryModelType.TASK_DETAIL, details, taskId);
     }
 
 	public void setup(Object... configurations) {

http://git-wip-us.apache.org/repos/asf/airavata/blob/04269ff8/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/monitor/AiravataWorkflowNodeStatusUpdator.java
----------------------------------------------------------------------
diff --git a/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/monitor/AiravataWorkflowNodeStatusUpdator.java b/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/monitor/AiravataWorkflowNodeStatusUpdator.java
index 66e7ecc..65cc2f2 100644
--- a/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/monitor/AiravataWorkflowNodeStatusUpdator.java
+++ b/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/monitor/AiravataWorkflowNodeStatusUpdator.java
@@ -28,7 +28,7 @@ import org.apache.airavata.model.workspace.experiment.ExperimentState;
 import org.apache.airavata.model.workspace.experiment.WorkflowNodeDetails;
 import org.apache.airavata.model.workspace.experiment.WorkflowNodeState;
 import org.apache.airavata.model.workspace.experiment.WorkflowNodeStatus;
-import org.apache.airavata.registry.cpi.DataType;
+import org.apache.airavata.registry.cpi.RegistryModelType;
 import org.apache.airavata.registry.cpi.Registry;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
@@ -87,7 +87,7 @@ public class AiravataWorkflowNodeStatusUpdator implements AbstractActivityListen
     }
 
     public  void updateWorkflowNodeStatus(String workflowNodeId, WorkflowNodeState state) throws Exception {
-    	WorkflowNodeDetails details = (WorkflowNodeDetails)airavataRegistry.get(DataType.WORKFLOW_NODE_DETAIL, workflowNodeId);
+    	WorkflowNodeDetails details = (WorkflowNodeDetails)airavataRegistry.get(RegistryModelType.WORKFLOW_NODE_DETAIL, workflowNodeId);
         if(details == null) {
             details = new WorkflowNodeDetails();
             details.setNodeInstanceId(workflowNodeId);
@@ -96,7 +96,7 @@ public class AiravataWorkflowNodeStatusUpdator implements AbstractActivityListen
         status.setWorkflowNodeState(state);
         status.setTimeOfStateChange(Calendar.getInstance().getTimeInMillis());
         details.setWorkflowNodeStatus(status);
-        airavataRegistry.update(DataType.WORKFLOW_NODE_DETAIL, details, workflowNodeId);
+        airavataRegistry.update(RegistryModelType.WORKFLOW_NODE_DETAIL, details, workflowNodeId);
     }
 
 	public void setup(Object... configurations) {

http://git-wip-us.apache.org/repos/asf/airavata/blob/04269ff8/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/utils/GFacUtils.java
----------------------------------------------------------------------
diff --git a/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/utils/GFacUtils.java b/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/utils/GFacUtils.java
index e13fa3f..7013f3e 100644
--- a/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/utils/GFacUtils.java
+++ b/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/utils/GFacUtils.java
@@ -619,7 +619,7 @@ public class GFacUtils {
 			status.setJobState(state);
 			status.setTimeOfStateChange(Calendar.getInstance().getTimeInMillis());
         	details.setJobStatus(status);
-			registry.update(org.apache.airavata.registry.cpi.DataType.JOB_DETAIL, details, details.getJobID());
+			registry.update(org.apache.airavata.registry.cpi.RegistryModelType.JOB_DETAIL, details, details.getJobID());
 		} catch (Exception e) {
 			throw new GFacException("Error persisting job status" + e.getLocalizedMessage(),e);
 		}

http://git-wip-us.apache.org/repos/asf/airavata/blob/04269ff8/modules/gfac/gfac-gsissh/src/main/java/org/apache/airavata/gfac/gsissh/handler/GSISSHOutputHandler.java
----------------------------------------------------------------------
diff --git a/modules/gfac/gfac-gsissh/src/main/java/org/apache/airavata/gfac/gsissh/handler/GSISSHOutputHandler.java b/modules/gfac/gfac-gsissh/src/main/java/org/apache/airavata/gfac/gsissh/handler/GSISSHOutputHandler.java
index bd4ede4..2f1bc13 100644
--- a/modules/gfac/gfac-gsissh/src/main/java/org/apache/airavata/gfac/gsissh/handler/GSISSHOutputHandler.java
+++ b/modules/gfac/gfac-gsissh/src/main/java/org/apache/airavata/gfac/gsissh/handler/GSISSHOutputHandler.java
@@ -54,7 +54,7 @@ import org.apache.airavata.model.workspace.experiment.TaskDetails;
 import org.apache.airavata.model.workspace.experiment.TransferState;
 import org.apache.airavata.model.workspace.experiment.TransferStatus;
 import org.apache.airavata.registry.cpi.ChildDataType;
-import org.apache.airavata.registry.cpi.DataType;
+import org.apache.airavata.registry.cpi.RegistryModelType;
 import org.apache.airavata.registry.cpi.RegistryException;
 import org.apache.airavata.schemas.gfac.ApplicationDeploymentDescriptionType;
 import org.apache.airavata.schemas.gfac.GsisshHostType;
@@ -73,7 +73,7 @@ public class GSISSHOutputHandler extends AbstractHandler {
                 ApplicationDescription applicationDeploymentDescription = jobExecutionContext.getApplicationContext().getApplicationDeploymentDescription();
                 TaskDetails taskData = null;
                 try {
-                    taskData = (TaskDetails) jobExecutionContext.getRegistry().get(DataType.TASK_DETAIL, jobExecutionContext.getTaskData().getTaskID());
+                    taskData = (TaskDetails) jobExecutionContext.getRegistry().get(RegistryModelType.TASK_DETAIL, jobExecutionContext.getTaskData().getTaskID());
                 } catch (RegistryException e) {
                     log.error("Error retrieving job details from Registry");
                     throw new GFacHandlerException("Error retrieving job details from Registry", e);

http://git-wip-us.apache.org/repos/asf/airavata/blob/04269ff8/modules/gfac/gfac-ssh/src/main/java/org/apache/airavata/gfac/ssh/handler/SSHOutputHandler.java
----------------------------------------------------------------------
diff --git a/modules/gfac/gfac-ssh/src/main/java/org/apache/airavata/gfac/ssh/handler/SSHOutputHandler.java b/modules/gfac/gfac-ssh/src/main/java/org/apache/airavata/gfac/ssh/handler/SSHOutputHandler.java
index 66296f2..c381805 100644
--- a/modules/gfac/gfac-ssh/src/main/java/org/apache/airavata/gfac/ssh/handler/SSHOutputHandler.java
+++ b/modules/gfac/gfac-ssh/src/main/java/org/apache/airavata/gfac/ssh/handler/SSHOutputHandler.java
@@ -48,7 +48,7 @@ import org.apache.airavata.gsi.ssh.api.Cluster;
 import org.apache.airavata.gsi.ssh.api.job.JobDescriptor;
 import org.apache.airavata.model.workspace.experiment.*;
 import org.apache.airavata.registry.cpi.ChildDataType;
-import org.apache.airavata.registry.cpi.DataType;
+import org.apache.airavata.registry.cpi.RegistryModelType;
 import org.apache.airavata.registry.cpi.RegistryException;
 import org.apache.airavata.schemas.gfac.ApplicationDeploymentDescriptionType;
 import org.apache.airavata.schemas.gfac.GsisshHostType;
@@ -69,7 +69,7 @@ public class SSHOutputHandler extends AbstractHandler {
                 ApplicationDescription applicationDeploymentDescription = jobExecutionContext.getApplicationContext().getApplicationDeploymentDescription();
                 TaskDetails taskData = null;
                 try {
-                    taskData = (TaskDetails) registry.get(DataType.TASK_DETAIL, jobExecutionContext.getTaskData().getTaskID());
+                    taskData = (TaskDetails) registry.get(RegistryModelType.TASK_DETAIL, jobExecutionContext.getTaskData().getTaskID());
                 } catch (RegistryException e) {
                     log.error("Error retrieving job details from Registry");
                     throw new GFacHandlerException("Error retrieving job details from Registry", e);

http://git-wip-us.apache.org/repos/asf/airavata/blob/04269ff8/modules/orchestrator/airavata-orchestrator-service/src/main/java/org/apache/airavata/orchestrator/server/OrchestratorServerHandler.java
----------------------------------------------------------------------
diff --git a/modules/orchestrator/airavata-orchestrator-service/src/main/java/org/apache/airavata/orchestrator/server/OrchestratorServerHandler.java b/modules/orchestrator/airavata-orchestrator-service/src/main/java/org/apache/airavata/orchestrator/server/OrchestratorServerHandler.java
index 86c0c5e..073f65d 100644
--- a/modules/orchestrator/airavata-orchestrator-service/src/main/java/org/apache/airavata/orchestrator/server/OrchestratorServerHandler.java
+++ b/modules/orchestrator/airavata-orchestrator-service/src/main/java/org/apache/airavata/orchestrator/server/OrchestratorServerHandler.java
@@ -32,7 +32,7 @@ import org.apache.airavata.orchestrator.cpi.OrchestratorService;
 import org.apache.airavata.orchestrator.cpi.orchestrator_cpi_serviceConstants;
 import org.apache.airavata.orchestrator.cpi.impl.SimpleOrchestratorImpl;
 import org.apache.airavata.persistance.registry.jpa.impl.RegistryFactory;
-import org.apache.airavata.registry.cpi.DataType;
+import org.apache.airavata.registry.cpi.RegistryModelType;
 import org.apache.airavata.registry.cpi.Registry;
 import org.apache.airavata.registry.cpi.utils.Constants.FieldConstants.TaskDetailConstants;
 import org.apache.airavata.registry.cpi.utils.Constants.FieldConstants.WorkflowNodeConstants;
@@ -86,14 +86,14 @@ public class OrchestratorServerHandler implements OrchestratorService.Iface {
             if (tasks.size() > 1) {
                 log.info("There are multiple tasks for this experiment, So Orchestrator will launch multiple Jobs");
             }
-            List<String> ids = registry.getIds(DataType.WORKFLOW_NODE_DETAIL,WorkflowNodeConstants.EXPERIMENT_ID,experimentId);
+            List<String> ids = registry.getIds(RegistryModelType.WORKFLOW_NODE_DETAIL,WorkflowNodeConstants.EXPERIMENT_ID,experimentId);
             for (String workflowNodeId : ids) {
-                WorkflowNodeDetails workflowNodeDetail = (WorkflowNodeDetails)registry.get(DataType.WORKFLOW_NODE_DETAIL, workflowNodeId);
-                List<Object> taskDetailList = registry.get(DataType.TASK_DETAIL, TaskDetailConstants.NODE_ID, workflowNodeId);
+                WorkflowNodeDetails workflowNodeDetail = (WorkflowNodeDetails)registry.get(RegistryModelType.WORKFLOW_NODE_DETAIL, workflowNodeId);
+                List<Object> taskDetailList = registry.get(RegistryModelType.TASK_DETAIL, TaskDetailConstants.NODE_ID, workflowNodeId);
                 for (Object o : taskDetailList) {
                     TaskDetails taskID = (TaskDetails) o;
                     //iterate through all the generated tasks and performs the job submisssion+monitoring
-                    Experiment experiment = (Experiment) registry.get(DataType.EXPERIMENT, experimentId);
+                    Experiment experiment = (Experiment) registry.get(RegistryModelType.EXPERIMENT, experimentId);
                     if (experiment == null) {
                         log.error("Error retrieving the Experiment by the given experimentID: " + experimentId);
                         return false;

http://git-wip-us.apache.org/repos/asf/airavata/blob/04269ff8/modules/orchestrator/orchestrator-core/src/main/java/org/apache/airavata/orchestrator/core/validator/impl/SimpleAppDataValidator.java
----------------------------------------------------------------------
diff --git a/modules/orchestrator/orchestrator-core/src/main/java/org/apache/airavata/orchestrator/core/validator/impl/SimpleAppDataValidator.java b/modules/orchestrator/orchestrator-core/src/main/java/org/apache/airavata/orchestrator/core/validator/impl/SimpleAppDataValidator.java
index 0f83e25..53ecfe8 100644
--- a/modules/orchestrator/orchestrator-core/src/main/java/org/apache/airavata/orchestrator/core/validator/impl/SimpleAppDataValidator.java
+++ b/modules/orchestrator/orchestrator-core/src/main/java/org/apache/airavata/orchestrator/core/validator/impl/SimpleAppDataValidator.java
@@ -48,7 +48,7 @@ public class SimpleAppDataValidator extends AbstractJobMetadataValidator {
 
             Experiment experiment = null;
             try {
-                experiment = (Experiment) registry.get(org.apache.airavata.registry.cpi.DataType.EXPERIMENT, experimentID);
+                experiment = (Experiment) registry.get(org.apache.airavata.registry.cpi.RegistryModelType.EXPERIMENT, experimentID);
             } catch (Exception e) {
                 throw new OrchestratorException(e);
             }

http://git-wip-us.apache.org/repos/asf/airavata/blob/04269ff8/modules/orchestrator/orchestrator-core/src/main/java/org/apache/airavata/orchestrator/cpi/impl/SimpleOrchestratorImpl.java
----------------------------------------------------------------------
diff --git a/modules/orchestrator/orchestrator-core/src/main/java/org/apache/airavata/orchestrator/cpi/impl/SimpleOrchestratorImpl.java b/modules/orchestrator/orchestrator-core/src/main/java/org/apache/airavata/orchestrator/cpi/impl/SimpleOrchestratorImpl.java
index e614a9e..afd7425 100644
--- a/modules/orchestrator/orchestrator-core/src/main/java/org/apache/airavata/orchestrator/cpi/impl/SimpleOrchestratorImpl.java
+++ b/modules/orchestrator/orchestrator-core/src/main/java/org/apache/airavata/orchestrator/cpi/impl/SimpleOrchestratorImpl.java
@@ -34,7 +34,7 @@ import org.apache.airavata.orchestrator.core.exception.OrchestratorException;
 import org.apache.airavata.orchestrator.core.job.JobSubmitter;
 import org.apache.airavata.orchestrator.core.validator.JobMetadataValidator;
 import org.apache.airavata.registry.cpi.ChildDataType;
-import org.apache.airavata.registry.cpi.DataType;
+import org.apache.airavata.registry.cpi.RegistryModelType;
 import org.apache.airavata.registry.cpi.Registry;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
@@ -108,7 +108,7 @@ public class SimpleOrchestratorImpl extends AbstractOrchestrator{
         List<TaskDetails> tasks = new ArrayList<TaskDetails>();
         try {
             Registry newRegistry = orchestratorContext.getNewRegistry();
-            experiment = (Experiment) newRegistry.get(DataType.EXPERIMENT, experimentId);
+            experiment = (Experiment) newRegistry.get(RegistryModelType.EXPERIMENT, experimentId);
 
 
             WorkflowNodeDetails iDontNeedaNode = ExperimentModelUtil.createWorkflowNode("IDontNeedaNode", null);

http://git-wip-us.apache.org/repos/asf/airavata/blob/04269ff8/modules/registry/airavata-jpa-registry/src/main/java/org/apache/airavata/persistance/registry/jpa/impl/ExperimentRegistry.java
----------------------------------------------------------------------
diff --git a/modules/registry/airavata-jpa-registry/src/main/java/org/apache/airavata/persistance/registry/jpa/impl/ExperimentRegistry.java b/modules/registry/airavata-jpa-registry/src/main/java/org/apache/airavata/persistance/registry/jpa/impl/ExperimentRegistry.java
index 3898418..952791b 100644
--- a/modules/registry/airavata-jpa-registry/src/main/java/org/apache/airavata/persistance/registry/jpa/impl/ExperimentRegistry.java
+++ b/modules/registry/airavata-jpa-registry/src/main/java/org/apache/airavata/persistance/registry/jpa/impl/ExperimentRegistry.java
@@ -29,7 +29,7 @@ import org.apache.airavata.persistance.registry.jpa.ResourceUtils;
 import org.apache.airavata.persistance.registry.jpa.resources.*;
 import org.apache.airavata.persistance.registry.jpa.utils.ThriftDataModelConversion;
 import org.apache.airavata.registry.cpi.CompositeIdentifier;
-import org.apache.airavata.registry.cpi.DataType;
+import org.apache.airavata.registry.cpi.RegistryModelType;
 import org.apache.airavata.registry.cpi.utils.Constants;
 import org.apache.airavata.registry.cpi.utils.StatusType;
 import org.slf4j.Logger;
@@ -1877,7 +1877,7 @@ public class ExperimentRegistry {
         }
     }
 
-    public ComputationalResourceScheduling getComputationalScheduling(DataType type, String id) throws Exception {
+    public ComputationalResourceScheduling getComputationalScheduling(RegistryModelType type, String id) throws Exception {
         try {
             ComputationSchedulingResource computationScheduling = null;
             switch (type) {
@@ -1902,7 +1902,7 @@ public class ExperimentRegistry {
         return null;
     }
 
-    public AdvancedInputDataHandling getInputDataHandling(DataType type, String id) throws Exception {
+    public AdvancedInputDataHandling getInputDataHandling(RegistryModelType type, String id) throws Exception {
         try {
             AdvanceInputDataHandlingResource dataHandlingResource = null;
             switch (type) {
@@ -1927,7 +1927,7 @@ public class ExperimentRegistry {
         return null;
     }
 
-    public AdvancedOutputDataHandling getOutputDataHandling(DataType type, String id) throws Exception {
+    public AdvancedOutputDataHandling getOutputDataHandling(RegistryModelType type, String id) throws Exception {
         try {
             AdvancedOutputDataHandlingResource dataHandlingResource = null;
             switch (type) {
@@ -1952,7 +1952,7 @@ public class ExperimentRegistry {
         return null;
     }
 
-    public QualityOfServiceParams getQosParams(DataType type, String id) throws Exception {
+    public QualityOfServiceParams getQosParams(RegistryModelType type, String id) throws Exception {
         try {
             QosParamResource qosParamResource = null;
             switch (type) {
@@ -2248,7 +2248,7 @@ public class ExperimentRegistry {
         }
     }
 
-    public void removeComputationalScheduling(DataType dataType, String id) throws Exception {
+    public void removeComputationalScheduling(RegistryModelType dataType, String id) throws Exception {
         try {
             switch (dataType) {
                 case EXPERIMENT:
@@ -2270,7 +2270,7 @@ public class ExperimentRegistry {
         }
     }
 
-    public void removeInputDataHandling(DataType dataType, String id) throws Exception {
+    public void removeInputDataHandling(RegistryModelType dataType, String id) throws Exception {
         try {
             switch (dataType) {
                 case EXPERIMENT:
@@ -2292,7 +2292,7 @@ public class ExperimentRegistry {
         }
     }
 
-    public void removeOutputDataHandling(DataType dataType, String id) throws Exception {
+    public void removeOutputDataHandling(RegistryModelType dataType, String id) throws Exception {
         try {
             switch (dataType) {
                 case EXPERIMENT:
@@ -2314,7 +2314,7 @@ public class ExperimentRegistry {
         }
     }
 
-    public void removeQOSParams(DataType dataType, String id) throws Exception {
+    public void removeQOSParams(RegistryModelType dataType, String id) throws Exception {
         try {
             switch (dataType) {
                 case EXPERIMENT:
@@ -2395,7 +2395,7 @@ public class ExperimentRegistry {
         }
     }
 
-    public boolean isComputationalSchedulingExist(DataType dataType, String id) throws Exception {
+    public boolean isComputationalSchedulingExist(RegistryModelType dataType, String id) throws Exception {
         try {
             switch (dataType) {
                 case EXPERIMENT:
@@ -2417,7 +2417,7 @@ public class ExperimentRegistry {
         return false;
     }
 
-    public boolean isInputDataHandlingExist(DataType dataType, String id) throws Exception {
+    public boolean isInputDataHandlingExist(RegistryModelType dataType, String id) throws Exception {
         try {
             switch (dataType) {
                 case EXPERIMENT:
@@ -2438,7 +2438,7 @@ public class ExperimentRegistry {
         return false;
     }
 
-    public boolean isOutputDataHandlingExist(DataType dataType, String id) throws Exception {
+    public boolean isOutputDataHandlingExist(RegistryModelType dataType, String id) throws Exception {
         try {
             switch (dataType) {
                 case EXPERIMENT:
@@ -2459,7 +2459,7 @@ public class ExperimentRegistry {
         return false;
     }
 
-    public boolean isQOSParamsExist(DataType dataType, String id) throws Exception {
+    public boolean isQOSParamsExist(RegistryModelType dataType, String id) throws Exception {
         try {
             switch (dataType) {
                 case EXPERIMENT:
@@ -2482,10 +2482,10 @@ public class ExperimentRegistry {
 
     public void updateScheduling(ComputationalResourceScheduling scheduling, String id, String type) throws Exception {
         try {
-            if (type.equals(DataType.EXPERIMENT.toString())) {
+            if (type.equals(RegistryModelType.EXPERIMENT.toString())) {
                 ExperimentResource experiment = gatewayResource.getExperiment(id);
                 updateSchedulingData(scheduling, experiment);
-            } else if (type.equals(DataType.TASK_DETAIL.toString())) {
+            } else if (type.equals(RegistryModelType.TASK_DETAIL.toString())) {
                 ExperimentResource experiment = (ExperimentResource) gatewayResource.create(ResourceType.EXPERIMENT);
                 WorkflowNodeDetailResource workflowNode = (WorkflowNodeDetailResource) experiment.create(ResourceType.WORKFLOW_NODE_DETAIL);
                 TaskDetailResource taskDetail = workflowNode.getTaskDetail(id);
@@ -2499,10 +2499,10 @@ public class ExperimentRegistry {
 
     public void updateInputDataHandling(AdvancedInputDataHandling dataHandling, String id, String type) throws Exception {
         try {
-            if (type.equals(DataType.EXPERIMENT.toString())) {
+            if (type.equals(RegistryModelType.EXPERIMENT.toString())) {
                 ExperimentResource experiment = gatewayResource.getExperiment(id);
                 updateInputDataHandling(dataHandling, experiment);
-            } else if (type.equals(DataType.TASK_DETAIL.toString())) {
+            } else if (type.equals(RegistryModelType.TASK_DETAIL.toString())) {
                 ExperimentResource experiment = (ExperimentResource) gatewayResource.create(ResourceType.EXPERIMENT);
                 WorkflowNodeDetailResource workflowNode = (WorkflowNodeDetailResource) experiment.create(ResourceType.WORKFLOW_NODE_DETAIL);
                 TaskDetailResource taskDetail = workflowNode.getTaskDetail(id);
@@ -2516,10 +2516,10 @@ public class ExperimentRegistry {
 
     public void updateOutputDataHandling(AdvancedOutputDataHandling dataHandling, String id, String type) throws Exception {
         try {
-            if (type.equals(DataType.EXPERIMENT.toString())) {
+            if (type.equals(RegistryModelType.EXPERIMENT.toString())) {
                 ExperimentResource experiment = gatewayResource.getExperiment(id);
                 updateOutputDataHandling(dataHandling, experiment);
-            } else if (type.equals(DataType.TASK_DETAIL.toString())) {
+            } else if (type.equals(RegistryModelType.TASK_DETAIL.toString())) {
                 ExperimentResource experiment = (ExperimentResource) gatewayResource.create(ResourceType.EXPERIMENT);
                 WorkflowNodeDetailResource workflowNode = (WorkflowNodeDetailResource) experiment.create(ResourceType.WORKFLOW_NODE_DETAIL);
                 TaskDetailResource taskDetail = workflowNode.getTaskDetail(id);
@@ -2533,10 +2533,10 @@ public class ExperimentRegistry {
 
     public void updateQOSParams(QualityOfServiceParams params, String id, String type) throws Exception {
         try {
-            if (type.equals(DataType.EXPERIMENT.toString())) {
+            if (type.equals(RegistryModelType.EXPERIMENT.toString())) {
                 ExperimentResource experiment = gatewayResource.getExperiment(id);
                 updateQosParams(params, experiment);
-            } else if (type.equals(DataType.TASK_DETAIL.toString())) {
+            } else if (type.equals(RegistryModelType.TASK_DETAIL.toString())) {
                 ExperimentResource experiment = (ExperimentResource) gatewayResource.create(ResourceType.EXPERIMENT);
                 WorkflowNodeDetailResource workflowNode = (WorkflowNodeDetailResource) experiment.create(ResourceType.WORKFLOW_NODE_DETAIL);
                 TaskDetailResource taskDetail = workflowNode.getTaskDetail(id);

http://git-wip-us.apache.org/repos/asf/airavata/blob/04269ff8/modules/registry/airavata-jpa-registry/src/main/java/org/apache/airavata/persistance/registry/jpa/impl/LoggingRegistryImpl.java
----------------------------------------------------------------------
diff --git a/modules/registry/airavata-jpa-registry/src/main/java/org/apache/airavata/persistance/registry/jpa/impl/LoggingRegistryImpl.java b/modules/registry/airavata-jpa-registry/src/main/java/org/apache/airavata/persistance/registry/jpa/impl/LoggingRegistryImpl.java
index 1c6f923..3e45bdb 100644
--- a/modules/registry/airavata-jpa-registry/src/main/java/org/apache/airavata/persistance/registry/jpa/impl/LoggingRegistryImpl.java
+++ b/modules/registry/airavata-jpa-registry/src/main/java/org/apache/airavata/persistance/registry/jpa/impl/LoggingRegistryImpl.java
@@ -37,35 +37,35 @@ public class LoggingRegistryImpl implements Registry {
         return null;  //To change body of implemented methods use File | Settings | File Templates.
     }
 
-    public void update(DataType dataType, Object newObjectToUpdate, Object identifier) throws RegistryException {
+    public void update(RegistryModelType dataType, Object newObjectToUpdate, Object identifier) throws RegistryException {
         //To change body of implemented methods use File | Settings | File Templates.
     }
 
-    public void update(DataType dataType, Object identifier, String fieldName, Object value) throws RegistryException {
+    public void update(RegistryModelType dataType, Object identifier, String fieldName, Object value) throws RegistryException {
         //To change body of implemented methods use File | Settings | File Templates.
     }
 
-    public Object get(DataType dataType, Object identifier) throws RegistryException {
+    public Object get(RegistryModelType dataType, Object identifier) throws RegistryException {
         return null;  //To change body of implemented methods use File | Settings | File Templates.
     }
 
-    public List<Object> get(DataType dataType, String fieldName, Object value) throws RegistryException {
+    public List<Object> get(RegistryModelType dataType, String fieldName, Object value) throws RegistryException {
         return null;  //To change body of implemented methods use File | Settings | File Templates.
     }
 
-    public Object getValue(DataType dataType, Object identifier, String field) throws RegistryException {
+    public Object getValue(RegistryModelType dataType, Object identifier, String field) throws RegistryException {
         return null;  //To change body of implemented methods use File | Settings | File Templates.
     }
 
-    public List<String> getIds(DataType dataType, String fieldName, Object value) throws RegistryException {
+    public List<String> getIds(RegistryModelType dataType, String fieldName, Object value) throws RegistryException {
         return null;  //To change body of implemented methods use File | Settings | File Templates.
     }
 
-    public void remove(DataType dataType, Object identifier) throws RegistryException {
+    public void remove(RegistryModelType dataType, Object identifier) throws RegistryException {
         //To change body of implemented methods use File | Settings | File Templates.
     }
 
-    public boolean isExist(DataType dataType, Object identifier) throws RegistryException {
+    public boolean isExist(RegistryModelType dataType, Object identifier) throws RegistryException {
         return false;  //To change body of implemented methods use File | Settings | File Templates.
     }
 }

http://git-wip-us.apache.org/repos/asf/airavata/blob/04269ff8/modules/registry/airavata-jpa-registry/src/main/java/org/apache/airavata/persistance/registry/jpa/impl/RegistryImpl.java
----------------------------------------------------------------------
diff --git a/modules/registry/airavata-jpa-registry/src/main/java/org/apache/airavata/persistance/registry/jpa/impl/RegistryImpl.java b/modules/registry/airavata-jpa-registry/src/main/java/org/apache/airavata/persistance/registry/jpa/impl/RegistryImpl.java
index 8acdab0..56c3734 100644
--- a/modules/registry/airavata-jpa-registry/src/main/java/org/apache/airavata/persistance/registry/jpa/impl/RegistryImpl.java
+++ b/modules/registry/airavata-jpa-registry/src/main/java/org/apache/airavata/persistance/registry/jpa/impl/RegistryImpl.java
@@ -169,7 +169,7 @@ public class RegistryImpl implements Registry {
      *                          other fields that need to be updated.
      */
     @Override
-    public void update(DataType dataType, Object newObjectToUpdate, Object identifier) throws RegistryException {
+    public void update(RegistryModelType dataType, Object newObjectToUpdate, Object identifier) throws RegistryException {
         try {
             switch (dataType) {
                 case PROJECT:
@@ -257,7 +257,7 @@ public class RegistryImpl implements Registry {
      *                   updated by given value
      */
     @Override
-    public void update(DataType dataType, Object identifier, String fieldName, Object value) throws RegistryException {
+    public void update(RegistryModelType dataType, Object identifier, String fieldName, Object value) throws RegistryException {
         try {
             switch (dataType) {
                 case EXPERIMENT:
@@ -288,7 +288,7 @@ public class RegistryImpl implements Registry {
      * @return object according to the given identifier.
      */
     @Override
-    public Object get(DataType dataType, Object identifier) throws RegistryException {
+    public Object get(RegistryModelType dataType, Object identifier) throws RegistryException {
         try {
             switch (dataType) {
                 case PROJECT:
@@ -352,7 +352,7 @@ public class RegistryImpl implements Registry {
      * @return List of objects according to the given criteria
      */
     @Override
-    public List<Object> get(DataType dataType, String fieldName, Object value) throws RegistryException {
+    public List<Object> get(RegistryModelType dataType, String fieldName, Object value) throws RegistryException {
         try {
             List<Object> result = new ArrayList<Object>();
             switch (dataType) {
@@ -428,7 +428,7 @@ public class RegistryImpl implements Registry {
      * given
      */
     @Override
-    public Object getValue(DataType dataType, Object identifier, String field) throws RegistryException {
+    public Object getValue(RegistryModelType dataType, Object identifier, String field) throws RegistryException {
         try {
             switch (dataType) {
                 case EXPERIMENT:
@@ -459,7 +459,7 @@ public class RegistryImpl implements Registry {
      * @return id list according to the filtering criteria
      */
     @Override
-    public List<String> getIds(DataType dataType, String fieldName, Object value) throws RegistryException {
+    public List<String> getIds(RegistryModelType dataType, String fieldName, Object value) throws RegistryException {
         try {
             switch (dataType) {
                 case PROJECT:
@@ -496,7 +496,7 @@ public class RegistryImpl implements Registry {
      *                   identifier will be generated experimentID
      */
     @Override
-    public void remove(DataType dataType, Object identifier) throws RegistryException {
+    public void remove(RegistryModelType dataType, Object identifier) throws RegistryException {
         try {
             switch (dataType) {
                 case PROJECT:
@@ -553,7 +553,7 @@ public class RegistryImpl implements Registry {
      * @return whether the given data type exists or not
      */
     @Override
-    public boolean isExist(DataType dataType, Object identifier) throws RegistryException {
+    public boolean isExist(RegistryModelType dataType, Object identifier) throws RegistryException {
         try {
             switch (dataType) {
                 case PROJECT:

http://git-wip-us.apache.org/repos/asf/airavata/blob/04269ff8/modules/registry/registry-cpi/src/main/java/org/apache/airavata/registry/cpi/DataType.java
----------------------------------------------------------------------
diff --git a/modules/registry/registry-cpi/src/main/java/org/apache/airavata/registry/cpi/DataType.java b/modules/registry/registry-cpi/src/main/java/org/apache/airavata/registry/cpi/DataType.java
deleted file mode 100644
index 9279e97..0000000
--- a/modules/registry/registry-cpi/src/main/java/org/apache/airavata/registry/cpi/DataType.java
+++ /dev/null
@@ -1,31 +0,0 @@
-package org.apache.airavata.registry.cpi;
-
-public enum DataType {
-    APPLiCATION_CATALOG,
-    GROUP,
-    USER,
-    PROJECT,
-    EXPERIMENT,
-    EXPERIMENT_INPUT,
-    EXPERIMENT_OUTPUT,
-    EXPERIMENT_STATUS,
-    WORKFLOW_NODE_DETAIL,
-    TASK_DETAIL,
-    WORKFLOW_NODE_STATUS,
-    TASK_STATUS,
-    APPLICATION_STATUS,
-    JOB_STATUS,
-    TRANSFER_STATUS,
-    ERROR_DETAIL,
-    APPLICATION_INPUT,
-    APPLICATION_OUTPUT,
-    NODE_INPUT,
-    NODE_OUTPUT,
-    JOB_DETAIL,
-    DATA_TRANSFER_DETAIL,
-    EXPERIMENT_CONFIGURATION_DATA,
-    COMPUTATIONAL_RESOURCE_SCHEDULING,
-    ADVANCE_INPUT_DATA_HANDLING,
-    ADVANCE_OUTPUT_DATA_HANDLING,
-    QOS_PARAM
-}

http://git-wip-us.apache.org/repos/asf/airavata/blob/04269ff8/modules/registry/registry-cpi/src/main/java/org/apache/airavata/registry/cpi/Registry.java
----------------------------------------------------------------------
diff --git a/modules/registry/registry-cpi/src/main/java/org/apache/airavata/registry/cpi/Registry.java b/modules/registry/registry-cpi/src/main/java/org/apache/airavata/registry/cpi/Registry.java
index 3e41ede..5665923 100644
--- a/modules/registry/registry-cpi/src/main/java/org/apache/airavata/registry/cpi/Registry.java
+++ b/modules/registry/registry-cpi/src/main/java/org/apache/airavata/registry/cpi/Registry.java
@@ -43,7 +43,7 @@ public interface Registry {
      *                       have to fill the whole object. He needs to only fill the mandatory fields and whatever the
      *                       other fields that need to be updated.
      */
-    public void update(DataType dataType, Object newObjectToUpdate, Object identifier) throws RegistryException;
+    public void update(RegistryModelType dataType, Object newObjectToUpdate, Object identifier) throws RegistryException;
 
 
     /**
@@ -58,7 +58,7 @@ public interface Registry {
      * @param value Value by which the given field need to be updated. If the field is "description", that field will be
      *              updated by given value
      */
-    public void update(DataType dataType, Object identifier, String fieldName, Object value) throws RegistryException;
+    public void update(RegistryModelType dataType, Object identifier, String fieldName, Object value) throws RegistryException;
 
     /**
      * This method is to retrieve object according to the identifier. In the experiment basic data type, if you give the
@@ -69,7 +69,7 @@ public interface Registry {
      *                   identifier will be generated experimentID
      * @return object according to the given identifier.
      */
-    public Object get(DataType dataType, Object identifier) throws RegistryException;
+    public Object get(RegistryModelType dataType, Object identifier) throws RegistryException;
 
     /**
      * This method is to retrieve list of objects according to a given criteria
@@ -80,7 +80,7 @@ public interface Registry {
      * @param value value for the filtering field. In the experiment case, value for "userName" can be "admin"
      * @return List of objects according to the given criteria
      */
-    public List<Object> get(DataType dataType, String fieldName, Object value) throws RegistryException;
+    public List<Object> get(RegistryModelType dataType, String fieldName, Object value) throws RegistryException;
 
     /**
      * This method is to retrieve a specific value for a given field.
@@ -93,7 +93,7 @@ public interface Registry {
      * @return return the value for the specific field where data model is identified by the unique identifier that has
      *         given
      */
-    public Object getValue (DataType dataType, Object identifier, String field) throws RegistryException;
+    public Object getValue (RegistryModelType dataType, Object identifier, String field) throws RegistryException;
 
     /**
      * This method is to retrieve all the identifiers according to given filtering criteria. For an example, if you want
@@ -106,7 +106,7 @@ public interface Registry {
      * @param value value for the filtering field. In the experiment case, value for "userName" can be "admin"
      * @return id list according to the filtering criteria
      */
-    public List<String> getIds (DataType dataType, String fieldName, Object value) throws RegistryException;
+    public List<String> getIds (RegistryModelType dataType, String fieldName, Object value) throws RegistryException;
 
     /**
      * This method is to remove a item from the registry
@@ -115,7 +115,7 @@ public interface Registry {
      * @param identifier Identifier which will uniquely identify the data model. For example, in Experiment_Basic_Type,
      *                   identifier will be generated experimentID
      */
-    public void remove (DataType dataType, Object identifier) throws RegistryException;
+    public void remove (RegistryModelType dataType, Object identifier) throws RegistryException;
 
     /**
      * This method will check whether a given data type which can be identified with the identifier exists or not
@@ -125,7 +125,7 @@ public interface Registry {
      *                   identifier will be generated experimentID
      * @return whether the given data type exists or not
      */
-    public boolean isExist(DataType dataType, Object identifier) throws RegistryException;
+    public boolean isExist(RegistryModelType dataType, Object identifier) throws RegistryException;
 
 
 }

http://git-wip-us.apache.org/repos/asf/airavata/blob/04269ff8/modules/registry/registry-cpi/src/main/java/org/apache/airavata/registry/cpi/RegistryModelType.java
----------------------------------------------------------------------
diff --git a/modules/registry/registry-cpi/src/main/java/org/apache/airavata/registry/cpi/RegistryModelType.java b/modules/registry/registry-cpi/src/main/java/org/apache/airavata/registry/cpi/RegistryModelType.java
new file mode 100644
index 0000000..bf4d1a7
--- /dev/null
+++ b/modules/registry/registry-cpi/src/main/java/org/apache/airavata/registry/cpi/RegistryModelType.java
@@ -0,0 +1,31 @@
+package org.apache.airavata.registry.cpi;
+
+public enum RegistryModelType {
+    APPLiCATION_CATALOG,
+    GROUP,
+    USER,
+    PROJECT,
+    EXPERIMENT,
+    EXPERIMENT_INPUT,
+    EXPERIMENT_OUTPUT,
+    EXPERIMENT_STATUS,
+    WORKFLOW_NODE_DETAIL,
+    TASK_DETAIL,
+    WORKFLOW_NODE_STATUS,
+    TASK_STATUS,
+    APPLICATION_STATUS,
+    JOB_STATUS,
+    TRANSFER_STATUS,
+    ERROR_DETAIL,
+    APPLICATION_INPUT,
+    APPLICATION_OUTPUT,
+    NODE_INPUT,
+    NODE_OUTPUT,
+    JOB_DETAIL,
+    DATA_TRANSFER_DETAIL,
+    EXPERIMENT_CONFIGURATION_DATA,
+    COMPUTATIONAL_RESOURCE_SCHEDULING,
+    ADVANCE_INPUT_DATA_HANDLING,
+    ADVANCE_OUTPUT_DATA_HANDLING,
+    QOS_PARAM
+}