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

[36/90] [abbrv] [partial] AIRAVATA-1124

http://git-wip-us.apache.org/repos/asf/airavata/blob/0e2c10f5/modules/rest/mappings/src/main/java/org/apache/airavata/rest/mappings/utils/DescriptorUtil.java
----------------------------------------------------------------------
diff --git a/modules/rest/mappings/src/main/java/org/apache/airavata/rest/mappings/utils/DescriptorUtil.java b/modules/rest/mappings/src/main/java/org/apache/airavata/rest/mappings/utils/DescriptorUtil.java
deleted file mode 100644
index aa4595f..0000000
--- a/modules/rest/mappings/src/main/java/org/apache/airavata/rest/mappings/utils/DescriptorUtil.java
+++ /dev/null
@@ -1,483 +0,0 @@
-/*
- *
- * 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.rest.mappings.utils;
-
-import java.util.ArrayList;
-import java.util.HashMap;
-import java.util.List;
-
-import org.apache.airavata.commons.gfac.type.ApplicationDescription;
-import org.apache.airavata.commons.gfac.type.HostDescription;
-import org.apache.airavata.commons.gfac.type.ServiceDescription;
-import org.apache.airavata.rest.mappings.resourcemappings.ApplicationDescriptor;
-import org.apache.airavata.rest.mappings.resourcemappings.HostDescriptor;
-import org.apache.airavata.rest.mappings.resourcemappings.ServiceDescriptor;
-import org.apache.airavata.rest.mappings.resourcemappings.ServiceParameters;
-import org.apache.airavata.schemas.gfac.ApplicationDeploymentDescriptionType;
-import org.apache.airavata.schemas.gfac.DataType;
-import org.apache.airavata.schemas.gfac.Ec2ApplicationDeploymentType;
-import org.apache.airavata.schemas.gfac.Ec2HostType;
-import org.apache.airavata.schemas.gfac.GlobusHostType;
-import org.apache.airavata.schemas.gfac.GsisshHostType;
-import org.apache.airavata.schemas.gfac.HostDescriptionType;
-import org.apache.airavata.schemas.gfac.HpcApplicationDeploymentType;
-import org.apache.airavata.schemas.gfac.InputParameterType;
-import org.apache.airavata.schemas.gfac.JobTypeType;
-import org.apache.airavata.schemas.gfac.NameValuePairType;
-import org.apache.airavata.schemas.gfac.OutputParameterType;
-import org.apache.airavata.schemas.gfac.ParameterType;
-import org.apache.airavata.schemas.gfac.ProjectAccountType;
-import org.apache.airavata.schemas.gfac.QueueType;
-import org.apache.airavata.schemas.gfac.SSHHostType;
-import org.apache.airavata.schemas.gfac.UnicoreHostType;
-
-public class DescriptorUtil {
-
-    public static HostDescription createHostDescription(String hostName, String hostAddress,
-                                                        String hostEndpoint, String gatekeeperEndpoint, String providerType) {
-        HostDescription host = new HostDescription();
-        host.getType().setHostName(hostName);
-        host.getType().setHostAddress(hostAddress);
-        if(providerType.equalsIgnoreCase(HostTypes.GLOBUS_HOST_TYPE)){
-        	 host.getType().changeType(GlobusHostType.type);
-             ((GlobusHostType) host.getType()).
-                     setGridFTPEndPointArray(new String[]{hostEndpoint});
-             ((GlobusHostType) host.getType()).
-                     setGlobusGateKeeperEndPointArray(new String[]{gatekeeperEndpoint});
-        }else if (providerType.equalsIgnoreCase(HostTypes.SSH_HOST_TYPE)){
-          	 host.getType().changeType(SSHHostType.type);
-        }else if (providerType.equalsIgnoreCase(HostTypes.UNICORE_HOST_TYPE)){
-        	 host.getType().changeType(GlobusHostType.type);
-             ((UnicoreHostType) host.getType()).
-                     setGridFTPEndPointArray(new String[]{hostEndpoint});
-             ((UnicoreHostType) host.getType()).
-                     setUnicoreBESEndPointArray(new String[]{gatekeeperEndpoint});
-        }
-        return host;
-    }
-
-    public static ApplicationDescription registerApplication(String appName, String exeuctableLocation, String scratchWorkingDirectory, String hostName,
-                                                                       String projAccNumber, String queueName, String cpuCount, String nodeCount, String maxMemory) throws Exception {
-        // Create Application Description
-        ApplicationDescription appDesc = new ApplicationDescription(HpcApplicationDeploymentType.type);
-        HpcApplicationDeploymentType app = (HpcApplicationDeploymentType) appDesc.getType();
-        app.setCpuCount(Integer.parseInt(cpuCount));
-        app.setNodeCount(Integer.parseInt(nodeCount));
-        ApplicationDeploymentDescriptionType.ApplicationName name = appDesc.getType().addNewApplicationName();
-        name.setStringValue(appName);
-        app.setExecutableLocation(exeuctableLocation);
-        app.setScratchWorkingDirectory(scratchWorkingDirectory);
-        ProjectAccountType projectAccountType = ((HpcApplicationDeploymentType) appDesc.getType()).addNewProjectAccount();
-        projectAccountType.setProjectAccountNumber(projAccNumber);
-        QueueType queueType = app.addNewQueue();
-        queueType.setQueueName(queueName);
-        app.setMaxMemory(Integer.parseInt(maxMemory));
-        return appDesc;
-    }
-
-    public static ServiceDescription getServiceDescription(String serviceName, String inputName, String inputType,
-                                                           String outputName, String outputType) {
-        // Create Service Description
-        ServiceDescription serv = new ServiceDescription();
-        serv.getType().setName(serviceName);
-
-        InputParameterType input = InputParameterType.Factory.newInstance();
-        input.setParameterName(inputName);
-        ParameterType parameterType = input.addNewParameterType();
-        parameterType.setType(DataType.Enum.forString(inputType));
-        parameterType.setName(inputName);
-        List<InputParameterType> inputList = new ArrayList<InputParameterType>();
-        inputList.add(input);
-        InputParameterType[] inputParamList = inputList.toArray(new InputParameterType[inputList
-                .size()]);
-
-        OutputParameterType output = OutputParameterType.Factory.newInstance();
-        output.setParameterName(outputName);
-        ParameterType parameterType1 = output.addNewParameterType();
-        parameterType1.setType(DataType.Enum.forString(outputType));
-        parameterType1.setName(outputName);
-        List<OutputParameterType> outputList = new ArrayList<OutputParameterType>();
-        outputList.add(output);
-        OutputParameterType[] outputParamList = outputList
-                .toArray(new OutputParameterType[outputList.size()]);
-        serv.getType().setInputParametersArray(inputParamList);
-        serv.getType().setOutputParametersArray(outputParamList);
-        return serv;
-    }
-
-
-    public static HostDescriptor createHostDescriptor (HostDescription hostDescription){
-        List<String> hostType = new ArrayList<String>();
-        List<String> gridFTPEndPoint = new ArrayList<String>();
-        List<String> gateKeeperEndPoint  = new ArrayList<String>();
-        List<String> imageID  = new ArrayList<String>();
-        List<String> instanceID  = new ArrayList<String>();
-
-        HostDescriptor hostDescriptor = new HostDescriptor();
-        hostDescriptor.setHostname(hostDescription.getType().getHostName());
-        hostDescriptor.setHostAddress(hostDescription.getType().getHostAddress());
-
-        HostDescriptionType hostDescriptionType = hostDescription.getType();
-        if (hostDescriptionType instanceof GlobusHostType){
-            GlobusHostType globusHostType = (GlobusHostType) hostDescriptionType;
-            hostType.add(HostTypes.GLOBUS_HOST_TYPE);
-            String[] globusGateKeeperEndPointArray = globusHostType.getGlobusGateKeeperEndPointArray();
-            for (int i = 0; i < globusGateKeeperEndPointArray.length ; i++){
-                gateKeeperEndPoint.add(globusGateKeeperEndPointArray[i]);
-            }
-
-            String[] gridFTPEndPointArray = globusHostType.getGridFTPEndPointArray();
-            for (int i = 0; i < gridFTPEndPointArray.length ; i++){
-                gridFTPEndPoint.add(gridFTPEndPointArray[i]);
-            }
-        }else if (hostDescriptionType instanceof GsisshHostType) {
-            hostType.add(HostTypes.GSISSH_HOST_TYPE);
-        } else if (hostDescriptionType instanceof SSHHostType) {
-            hostType.add(HostTypes.SSH_HOST_TYPE);
-            SSHHostType sshHostType = (SSHHostType) hostDescriptionType;
-            hostDescriptor.setHpcResource(sshHostType.getHpcResource());
-        } else if (hostDescriptionType instanceof UnicoreHostType) {
-            UnicoreHostType unicoreHostType = (UnicoreHostType) hostDescriptionType;
-            hostType.add(HostTypes.UNICORE_HOST_TYPE);
-            String[] unicoreGateKeeperEndPointArray = unicoreHostType.getUnicoreBESEndPointArray();
-            for (int i = 0; i < unicoreGateKeeperEndPointArray.length; i++) {
-                gateKeeperEndPoint.add(unicoreGateKeeperEndPointArray[i]);
-            }
-
-            String[] gridFTPEndPointArray = unicoreHostType.getGridFTPEndPointArray();
-            for (int i = 0; i < gridFTPEndPointArray.length; i++) {
-                gridFTPEndPoint.add(gridFTPEndPointArray[i]);
-            }
-        } else if (hostDescriptionType instanceof Ec2HostType) {
-            hostType.add(HostTypes.EC2_HOST_TYPE);
-        } else {
-            hostType.add(HostTypes.HOST_DESCRIPTION_TYPE);
-        }
-        hostDescriptor.setGateKeeperEndPoint(gateKeeperEndPoint);
-        hostDescriptor.setGridFTPEndPoint(gridFTPEndPoint);
-        hostDescriptor.setImageID(imageID);
-        hostDescriptor.setInstanceID(instanceID);
-        hostDescriptor.setHostType(hostType);
-        return hostDescriptor;
-    }
-
-    public static HostDescription createHostDescription (HostDescriptor hostDescriptor){
-        HostDescription hostDescription = new HostDescription(HostDescriptionType.type);
-        hostDescription.getType().setHostAddress(hostDescriptor.getHostAddress());
-        hostDescription.getType().setHostName(hostDescriptor.getHostname());
-
-        if (hostDescriptor.getHostType() != null && !hostDescriptor.getHostType().isEmpty()) {
-            if (hostDescriptor.getHostType().get(0).equals(HostTypes.GLOBUS_HOST_TYPE)) {
-                hostDescription.getType().changeType(GlobusHostType.type);
-                if (!hostDescriptor.getGateKeeperEndPoint().isEmpty() && hostDescriptor.getGateKeeperEndPoint() != null){
-                    ((GlobusHostType) hostDescription.getType()).addGlobusGateKeeperEndPoint(hostDescriptor.getGateKeeperEndPoint().get(0));
-                }
-                if (!hostDescriptor.getGridFTPEndPoint().isEmpty() && hostDescriptor.getGridFTPEndPoint() != null){
-                    ((GlobusHostType) hostDescription.getType()).addGridFTPEndPoint(hostDescriptor.getGridFTPEndPoint().get(0));
-                }
-
-            } else if (hostDescriptor.getHostType().get(0).equals(HostTypes.GSISSH_HOST_TYPE)) {
-                hostDescription.getType().changeType(GsisshHostType.type);
-            } else if (hostDescriptor.getHostType().get(0).equals(HostTypes.EC2_HOST_TYPE)) {
-                hostDescription.getType().changeType(Ec2HostType.type);
-                if (!hostDescriptor.getImageID().isEmpty() && hostDescriptor.getImageID() != null ){
-                    ((Ec2HostType) hostDescription).addImageID(hostDescriptor.getImageID().get(0));
-                }
-                if (!hostDescriptor.getInstanceID().isEmpty() && hostDescriptor.getInstanceID() != null){
-                    ((Ec2HostType) hostDescription).addInstanceID(hostDescriptor.getInstanceID().get(0));
-                }
-
-            }else if (hostDescriptor.getHostType().get(0).equals(HostTypes.SSH_HOST_TYPE)) {
-            	hostDescription.getType().changeType(SSHHostType.type);
-                ((SSHHostType)hostDescription.getType()).setHpcResource(hostDescriptor.isHpcResource());
-            } else if (hostDescriptor.getHostType().get(0).equals(HostTypes.UNICORE_HOST_TYPE)) {
-                 hostDescription.getType().changeType(UnicoreHostType.type);
-                 if (!hostDescriptor.getGateKeeperEndPoint().isEmpty() && hostDescriptor.getGateKeeperEndPoint() != null){
-                     ((UnicoreHostType) hostDescription.getType()).addUnicoreBESEndPoint(hostDescriptor.getGateKeeperEndPoint().get(0));
-                 }
-                 if (!hostDescriptor.getGridFTPEndPoint().isEmpty() && hostDescriptor.getGridFTPEndPoint() != null){
-                     ((UnicoreHostType) hostDescription.getType()).addGridFTPEndPoint(hostDescriptor.getGridFTPEndPoint().get(0));
-                 }
-            }
-        }
-
-        return hostDescription;
-    }
-
-    public static ServiceDescription createServiceDescription (ServiceDescriptor serviceDescriptor){
-        ServiceDescription serviceDescription = new ServiceDescription();
-        serviceDescription.getType().setName(serviceDescriptor.getServiceName());
-        serviceDescription.getType().setDescription(serviceDescriptor.getDescription());
-        List<ServiceParameters> inputParams = serviceDescriptor.getInputParams();
-        InputParameterType[] inputParameterTypeArray = new InputParameterType[inputParams.size()];
-        for (int i = 0; i < inputParams.size(); i++){
-            InputParameterType parameter = InputParameterType.Factory.newInstance();
-            parameter.setParameterName(inputParams.get(i).getName());
-            parameter.setParameterValueArray(new String[]{inputParams.get(i).getName()});
-            parameter.setParameterDescription(inputParams.get(i).getDescription());
-            ParameterType parameterType = parameter.addNewParameterType();
-            parameterType.setType(DataType.Enum.forString(inputParams.get(i).getType()));
-            parameterType.setName(inputParams.get(i).getType());
-            parameter.setParameterType(parameterType);
-            inputParameterTypeArray[i] = parameter;
-        }
-        serviceDescription.getType().setInputParametersArray(inputParameterTypeArray);
-
-        List<ServiceParameters> outputParams = serviceDescriptor.getOutputParams();
-        OutputParameterType[] outputParameterTypeArray = new OutputParameterType[outputParams.size()];
-        for (int i = 0; i < outputParams.size(); i++){
-            OutputParameterType parameter = OutputParameterType.Factory.newInstance();
-            parameter.setParameterName(outputParams.get(i).getName());
-            parameter.setParameterDescription(outputParams.get(i).getDescription());
-            ParameterType parameterType = parameter.addNewParameterType();
-            parameterType.setType(DataType.Enum.forString(outputParams.get(i).getType()));
-            parameterType.setName(outputParams.get(i).getType());
-            parameter.setParameterType(parameterType);
-            outputParameterTypeArray[i] = parameter;
-        }
-        serviceDescription.getType().setOutputParametersArray(outputParameterTypeArray);
-        return serviceDescription;
-    }
-
-    public static ServiceDescriptor createServiceDescriptor(ServiceDescription serviceDescription){
-        ServiceDescriptor serviceDescriptor = new ServiceDescriptor();
-        serviceDescriptor.setServiceName(serviceDescription.getType().getName());
-        serviceDescriptor.setDescription(serviceDescription.getType().getDescription());
-        InputParameterType[] inputParametersArray = serviceDescription.getType().getInputParametersArray();
-        OutputParameterType[] outputParametersArray = serviceDescription.getType().getOutputParametersArray();
-        List<ServiceParameters> inputParams = new ArrayList<ServiceParameters>();
-        List<ServiceParameters> outputParams = new ArrayList<ServiceParameters>();
-
-        for (int i = 0; i < inputParametersArray.length; i++){
-            ServiceParameters serviceParameters = new ServiceParameters();
-            serviceParameters.setType(inputParametersArray[i].getParameterType().getType().toString());
-//            String[] parameterValueArray = inputParametersArray[i].getParameterValueArray();
-//            if (parameterValueArray.length != 0){
-//                serviceParameters.setName(parameterValueArray[0]);
-//            }
-            serviceParameters.setName(inputParametersArray[i].getParameterName());
-            serviceParameters.setDescription(inputParametersArray[i].getParameterDescription());
-//            serviceParameters.set(inputParametersArray[i].getParameterType().getType().toString());
-            inputParams.add(serviceParameters);
-        }
-        serviceDescriptor.setInputParams(inputParams);
-
-        for (int i = 0; i < outputParametersArray.length; i++){
-            ServiceParameters serviceParameters = new ServiceParameters();
-            serviceParameters.setType(outputParametersArray[i].getParameterType().getType().toString());
-            serviceParameters.setName(outputParametersArray[i].getParameterName());
-            serviceParameters.setDescription(outputParametersArray[i].getParameterDescription());
-//            serviceParameters.setDataType(outputParametersArray[i].getParameterType().getType().toString());
-            outputParams.add(serviceParameters);
-        }
-        serviceDescriptor.setOutputParams(outputParams);
-        return serviceDescriptor;
-    }
-
-    public static ApplicationDescription createApplicationDescription(ApplicationDescriptor applicationDescriptor){
-        ApplicationDescription applicationDescription = new ApplicationDescription();
-        ApplicationDeploymentDescriptionType.ApplicationName name = ApplicationDeploymentDescriptionType.ApplicationName.Factory.newInstance();
-        name.setStringValue(applicationDescriptor.getName());
-        applicationDescription.getType().setApplicationName(name);
-        applicationDescription.getType().setExecutableLocation(applicationDescriptor.getExecutablePath());
-        applicationDescription.getType().setScratchWorkingDirectory(applicationDescriptor.getWorkingDir());
-
-        if (applicationDescriptor.getInputDir() != null){
-            applicationDescription.getType().setInputDataDirectory(applicationDescriptor.getInputDir());
-        }
-        if (applicationDescriptor.getOutputDir() != null){
-            applicationDescription.getType().setOutputDataDirectory(applicationDescriptor.getOutputDir());
-        }
-        if (applicationDescriptor.getStdIn() != null){
-            applicationDescription.getType().setStandardInput(applicationDescriptor.getStdIn());
-        }
-        if (applicationDescriptor.getStdOut() != null){
-            applicationDescription.getType().setStandardOutput(applicationDescriptor.getStdOut());
-        }
-        if (applicationDescriptor.getStdError() != null){
-            applicationDescription.getType().setStandardError(applicationDescriptor.getStdError());
-        }
-        if (applicationDescriptor.getStaticWorkigDir() != null){
-            applicationDescription.getType().setStaticWorkingDirectory(applicationDescriptor.getStaticWorkigDir());
-        }
-        HashMap<String,String> environmentVariables = applicationDescriptor.getEnvironmentVariables();
-        if (environmentVariables != null && !environmentVariables.isEmpty()){
-            NameValuePairType[] appEnviVariablesArray = new NameValuePairType[environmentVariables.size()];
-            for(String key : environmentVariables.keySet()) {
-                int i = 0;
-                NameValuePairType nameValuePairType = applicationDescription.getType().addNewApplicationEnvironment();
-                nameValuePairType.setName(key);
-                nameValuePairType.setValue(environmentVariables.get(key));
-                appEnviVariablesArray[i] = nameValuePairType;
-                i++;
-            }
-            applicationDescription.getType().setApplicationEnvironmentArray(appEnviVariablesArray);
-        }
-
-        //set advanced options according app desc type
-        if(applicationDescriptor.getApplicationDescType() != null && !applicationDescriptor.getApplicationDescType().isEmpty()){
-            if (applicationDescriptor.getApplicationDescType().equals(ApplicationDescriptorTypes.HPC_APP_DEP_DESC_TYPE)){
-                ApplicationDescription appDesc = new ApplicationDescription(HpcApplicationDeploymentType.type);
-                appDesc.getType().setApplicationName(name);
-                appDesc.getType().setExecutableLocation(applicationDescriptor.getExecutablePath());
-                appDesc.getType().setScratchWorkingDirectory(applicationDescriptor.getWorkingDir());
-
-                if (applicationDescriptor.getInputDir() != null){
-                    appDesc.getType().setInputDataDirectory(applicationDescriptor.getInputDir());
-                }
-                if (applicationDescriptor.getOutputDir() != null){
-                    appDesc.getType().setOutputDataDirectory(applicationDescriptor.getOutputDir());
-                }
-                if (applicationDescriptor.getStdIn() != null){
-                    appDesc.getType().setStandardInput(applicationDescriptor.getStdIn());
-                }
-                if (applicationDescriptor.getStdOut() != null){
-                    appDesc.getType().setStandardOutput(applicationDescriptor.getStdOut());
-                }
-                if (applicationDescriptor.getStdError() != null){
-                    appDesc.getType().setStandardError(applicationDescriptor.getStdError());
-                }
-                if (applicationDescriptor.getStaticWorkigDir() != null){
-                    appDesc.getType().setStaticWorkingDirectory(applicationDescriptor.getStaticWorkigDir());
-                }
-
-                HashMap<String,String> envVariables = applicationDescriptor.getEnvironmentVariables();
-                if (envVariables != null && !envVariables.isEmpty()){
-                    NameValuePairType[] appEnviVariablesArray = new NameValuePairType[envVariables.size()];
-                    for(String key : envVariables.keySet()) {
-                        int i = 0;
-                        NameValuePairType nameValuePairType = applicationDescription.getType().addNewApplicationEnvironment();
-                        nameValuePairType.setName(key);
-                        nameValuePairType.setValue(envVariables.get(key));
-                        appEnviVariablesArray[i] = nameValuePairType;
-                        i++;
-                    }
-                    appDesc.getType().setApplicationEnvironmentArray(appEnviVariablesArray);
-                }
-
-                HpcApplicationDeploymentType app = (HpcApplicationDeploymentType) appDesc.getType();
-
-                ProjectAccountType projectAccountType = app.addNewProjectAccount();
-                if (applicationDescriptor.getProjectNumber() != null){
-                    projectAccountType.setProjectAccountNumber(applicationDescriptor.getProjectNumber());
-                }
-                if (applicationDescriptor.getProjectDescription() != null){
-                    projectAccountType.setProjectAccountDescription(applicationDescriptor.getProjectDescription());
-                }
-                app.setProjectAccount(projectAccountType);
-
-                app.setCpuCount(applicationDescriptor.getCpuCount());
-                if (applicationDescriptor.getJobType() != null){
-                    app.setJobType(JobTypeType.Enum.forString(applicationDescriptor.getJobType()));
-                }
-                app.setInstalledParentPath(applicationDescriptor.getInstalledPath());
-                app.setJobSubmitterCommand(applicationDescriptor.getJobSubmitterCommand());
-                app.setMaxMemory(applicationDescriptor.getMaxMemory());
-                app.setMinMemory(applicationDescriptor.getMinMemory());
-                app.setMaxWallTime(applicationDescriptor.getMaxWallTime());
-                app.setNodeCount(applicationDescriptor.getNodeCount());
-                app.setProcessorsPerNode(applicationDescriptor.getProcessorsPerNode());
-
-                QueueType queueType = app.addNewQueue();
-                if (applicationDescriptor.getQueueName() != null){
-                    queueType.setQueueName(applicationDescriptor.getQueueName());
-                }
-                app.setQueue(queueType);
-
-                return appDesc;
-            }
-        }
-        return applicationDescription;
-    }
-
-    public static ApplicationDescriptor createApplicationDescriptor (ApplicationDescription applicationDescription){
-        ApplicationDescriptor applicationDescriptor = new ApplicationDescriptor();
-        applicationDescriptor.setName(applicationDescription.getType().getApplicationName().getStringValue());
-        applicationDescriptor.setExecutablePath(applicationDescription.getType().getExecutableLocation());
-        applicationDescriptor.setWorkingDir(applicationDescription.getType().getScratchWorkingDirectory());
-
-        if (applicationDescription.getType().getInputDataDirectory() != null && !applicationDescription.getType().getInputDataDirectory().equals("") ){
-            applicationDescriptor.setInputDir(applicationDescription.getType().getInputDataDirectory());
-        }
-        if (applicationDescription.getType().getOutputDataDirectory() != null && !applicationDescription.getType().getOutputDataDirectory().equals("")){
-            applicationDescriptor.setOutputDir(applicationDescription.getType().getOutputDataDirectory());
-        }
-        if (applicationDescription.getType().getStaticWorkingDirectory() != null && !applicationDescription.getType().getStaticWorkingDirectory().equals("")){
-            applicationDescriptor.setStaticWorkigDir(applicationDescription.getType().getStaticWorkingDirectory());
-        }
-        if (applicationDescription.getType().getStandardInput() != null && !applicationDescription.getType().getStandardInput().equals("")){
-            applicationDescriptor.setStdIn(applicationDescription.getType().getStandardInput());
-        }
-        if (applicationDescription.getType().getStandardOutput() != null && !applicationDescription.getType().getStandardOutput().equals("")){
-            applicationDescriptor.setStdOut(applicationDescription.getType().getStandardOutput());
-        }
-        if (applicationDescription.getType().getStandardError() != null && !applicationDescription.getType().getStandardError().equals("")){
-            applicationDescriptor.setStdError(applicationDescription.getType().getStandardError());
-        }
-        NameValuePairType[] environmentArray = applicationDescription.getType().getApplicationEnvironmentArray();
-        HashMap<String, String> environmentVariableMap = new HashMap<String, String>();
-        if (environmentArray != null && environmentArray.length != 0){
-            for (NameValuePairType nameValuePairType : environmentArray){
-                environmentVariableMap.put(nameValuePairType.getName(), nameValuePairType.getValue());
-            }
-            applicationDescriptor.setEnvironmentVariables(environmentVariableMap);
-        }
-
-        if(applicationDescription.getType() != null){
-            if(applicationDescription.getType() instanceof HpcApplicationDeploymentType){
-                applicationDescriptor.setApplicationDescType(ApplicationDescriptorTypes.HPC_APP_DEP_DESC_TYPE);
-                HpcApplicationDeploymentType gramApplicationDeploymentType = (HpcApplicationDeploymentType) applicationDescription.getType();
-                if(gramApplicationDeploymentType != null){
-                    applicationDescriptor.setCpuCount(gramApplicationDeploymentType.getCpuCount());
-                    applicationDescriptor.setNodeCount(gramApplicationDeploymentType.getNodeCount());
-                    applicationDescriptor.setMaxMemory(gramApplicationDeploymentType.getMaxMemory());
-                    applicationDescriptor.setMinMemory(gramApplicationDeploymentType.getMinMemory());
-                    applicationDescriptor.setMaxWallTime(gramApplicationDeploymentType.getMaxWallTime());
-                    applicationDescriptor.setJobSubmitterCommand(gramApplicationDeploymentType.getJobSubmitterCommand());
-                    applicationDescriptor.setInstalledPath(gramApplicationDeploymentType.getInstalledParentPath());
-                    if (gramApplicationDeploymentType.getJobType() != null)  {
-                        applicationDescriptor.setJobType(gramApplicationDeploymentType.getJobType().toString());
-                    }
-                    if (gramApplicationDeploymentType.getProjectAccount() != null){
-                        if (gramApplicationDeploymentType.getProjectAccount().getProjectAccountNumber() != null){
-                            applicationDescriptor.setProjectNumber(gramApplicationDeploymentType.getProjectAccount().getProjectAccountNumber());
-                        }
-                    }
-                    if (gramApplicationDeploymentType.getProjectAccount() != null){
-                        if (gramApplicationDeploymentType.getProjectAccount().getProjectAccountDescription() != null){
-                            applicationDescriptor.setProjectDescription(gramApplicationDeploymentType.getProjectAccount().getProjectAccountDescription());
-                        }
-                    }
-                    if(gramApplicationDeploymentType.getQueue() != null){
-                        applicationDescriptor.setQueueName(gramApplicationDeploymentType.getQueue().getQueueName());
-                    }
-                    applicationDescriptor.setProcessorsPerNode(gramApplicationDeploymentType.getProcessorsPerNode());
-                }
-            } else if (applicationDescription.getType() instanceof Ec2ApplicationDeploymentType) {
-                applicationDescriptor.setApplicationDescType(ApplicationDescriptorTypes.EC2_APP_DEP_DESC_TYPE);
-            }
-        }
-
-        return applicationDescriptor;
-    }
-
-}

http://git-wip-us.apache.org/repos/asf/airavata/blob/0e2c10f5/modules/rest/mappings/src/main/java/org/apache/airavata/rest/mappings/utils/HostTypes.java
----------------------------------------------------------------------
diff --git a/modules/rest/mappings/src/main/java/org/apache/airavata/rest/mappings/utils/HostTypes.java b/modules/rest/mappings/src/main/java/org/apache/airavata/rest/mappings/utils/HostTypes.java
deleted file mode 100644
index 0866955..0000000
--- a/modules/rest/mappings/src/main/java/org/apache/airavata/rest/mappings/utils/HostTypes.java
+++ /dev/null
@@ -1,32 +0,0 @@
-/*
- *
- * 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.rest.mappings.utils;
-
-public class HostTypes {
-    public static final String GLOBUS_HOST_TYPE = "GlobusHostType";
-    public static final String GSISSH_HOST_TYPE = "GsisshHostType";
-    public static final String EC2_HOST_TYPE = "Ec2HostType";
-    public static final String SSH_HOST_TYPE = "SSHHostType";
-    public static final String UNICORE_HOST_TYPE = "UnicoreHostType";
-    public static final String HOST_DESCRIPTION_TYPE = "HostDescriptionType";
-
-}

http://git-wip-us.apache.org/repos/asf/airavata/blob/0e2c10f5/modules/rest/mappings/src/main/java/org/apache/airavata/rest/mappings/utils/RegIdentifier.java
----------------------------------------------------------------------
diff --git a/modules/rest/mappings/src/main/java/org/apache/airavata/rest/mappings/utils/RegIdentifier.java b/modules/rest/mappings/src/main/java/org/apache/airavata/rest/mappings/utils/RegIdentifier.java
deleted file mode 100644
index 7e05f65..0000000
--- a/modules/rest/mappings/src/main/java/org/apache/airavata/rest/mappings/utils/RegIdentifier.java
+++ /dev/null
@@ -1,40 +0,0 @@
-/*
- *
- * 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.rest.mappings.utils;
-
-public class RegIdentifier {
-    private String user;
-    private String gateway;
-
-    public RegIdentifier(String user, String gateway) {
-        this.user = user;
-        this.gateway = gateway;
-    }
-
-    public String getUser() {
-        return user;
-    }
-
-    public String getGateway() {
-        return gateway;
-    }
-}

http://git-wip-us.apache.org/repos/asf/airavata/blob/0e2c10f5/modules/rest/mappings/src/main/java/org/apache/airavata/rest/mappings/utils/RegPoolUtils.java
----------------------------------------------------------------------
diff --git a/modules/rest/mappings/src/main/java/org/apache/airavata/rest/mappings/utils/RegPoolUtils.java b/modules/rest/mappings/src/main/java/org/apache/airavata/rest/mappings/utils/RegPoolUtils.java
deleted file mode 100644
index 6e1d5bd..0000000
--- a/modules/rest/mappings/src/main/java/org/apache/airavata/rest/mappings/utils/RegPoolUtils.java
+++ /dev/null
@@ -1,100 +0,0 @@
-/*
- *
- * 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.rest.mappings.utils;
-
-import org.apache.airavata.common.context.WorkflowContext;
-import org.apache.airavata.common.exception.AiravataConfigurationException;
-import org.apache.airavata.registry.api.AiravataRegistry2;
-import org.apache.airavata.registry.api.AiravataRegistryFactory;
-import org.apache.airavata.registry.api.AiravataUser;
-import org.apache.airavata.registry.api.Gateway;
-import org.apache.airavata.registry.api.exception.*;
-
-import javax.servlet.ServletContext;
-import java.util.Map;
-
-
-public class RegPoolUtils {
-
-    private final static Object lock = new Object();
-
-
-    public static AiravataRegistry2 acquireRegistry(ServletContext context) {
-        AiravataRegistry2 airavataRegistry=null;
-        String user =  WorkflowContext.getRequestUser();
-        String gatewayId = WorkflowContext.getGatewayId();
-        Gateway gateway = new Gateway(gatewayId);
-        AiravataUser airavataUser = new AiravataUser(user);
-        /*RegistryInstancesPool registryInstancesPool =
-                (RegistryInstancesPool) context.getAttribute(RestServicesConstants.AIRAVATA_REGISTRY_POOL);
-        Map<RegIdentifier,AiravataRegistry2> registryMap = registryInstancesPool.getRegistryInstancesList();
-        boolean foundReg=false;*/
-        try{
-            return AiravataRegistryFactory.getRegistry(gateway, airavataUser);
-            /*while(!foundReg){
-                synchronized (lock){
-                    RegIdentifier identifier = new RegIdentifier(user, gateway.getGatewayName());
-                    if (registryMap.size()==0){
-                        registryMap.put(identifier,
-                                AiravataRegistryFactory.getRegistry(gateway, airavataUser));
-                    }else {
-                        airavataRegistry = registryMap.get(identifier);
-                        if (airavataRegistry == null){
-                            registryMap.put(identifier,
-                                    AiravataRegistryFactory.getRegistry(gateway, airavataUser));
-                        }
-                    }
-                    airavataRegistry=registryMap.get(identifier);
-                    registryMap.remove(identifier);
-                    foundReg=true;
-                }
-            }*/
-        }catch (RegistryAccessorInvalidException e) {
-            e.printStackTrace();
-        } catch (RegistryAccessorInstantiateException e) {
-            e.printStackTrace();
-        } catch (RegistryAccessorUndefinedException e) {
-            e.printStackTrace();
-        } catch (RegistryAccessorNotFoundException e) {
-            e.printStackTrace();
-        } catch (AiravataConfigurationException e) {
-            e.printStackTrace();
-        } catch (RegistryException e) {
-            e.printStackTrace();
-        }
-        return airavataRegistry;
-    }
-
-    public static void releaseRegistry(ServletContext context, AiravataRegistry2 airavataRegistry) {
-        /*RegistryInstancesPool registryInstancesPool =
-                (RegistryInstancesPool)context.getAttribute(RestServicesConstants.AIRAVATA_REGISTRY_POOL);
-        Map<RegIdentifier, AiravataRegistry2> registryInstancesList =
-                registryInstancesPool.getRegistryInstancesList();
-        synchronized (lock){
-            RegIdentifier regIdentifier =
-                    new RegIdentifier(airavataRegistry.getUser().getUserName(),
-                            airavataRegistry.getGateway().getGatewayName());
-            registryInstancesList.put(regIdentifier, airavataRegistry);
-        } */
-    }
-
-}

http://git-wip-us.apache.org/repos/asf/airavata/blob/0e2c10f5/modules/rest/mappings/src/main/java/org/apache/airavata/rest/mappings/utils/RegistryInstancesPool.java
----------------------------------------------------------------------
diff --git a/modules/rest/mappings/src/main/java/org/apache/airavata/rest/mappings/utils/RegistryInstancesPool.java b/modules/rest/mappings/src/main/java/org/apache/airavata/rest/mappings/utils/RegistryInstancesPool.java
deleted file mode 100644
index 5a5d7bb..0000000
--- a/modules/rest/mappings/src/main/java/org/apache/airavata/rest/mappings/utils/RegistryInstancesPool.java
+++ /dev/null
@@ -1,50 +0,0 @@
-/*
- *
- * 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.rest.mappings.utils;
-
-import org.apache.airavata.registry.api.AiravataRegistry2;
-
-import java.util.HashMap;
-import java.util.Map;
-
-public class RegistryInstancesPool {
-    private Map<RegIdentifier, AiravataRegistry2> registryInstancesList = new HashMap<RegIdentifier, AiravataRegistry2>();
-    private int maxSize;
-
-    public RegistryInstancesPool(int maxSize) {
-        this.maxSize = maxSize;
-    }
-
-    public int getMaxSize() {
-        return maxSize;
-    }
-
-    public Map<RegIdentifier, AiravataRegistry2> getRegistryInstancesList() {
-        return registryInstancesList;
-    }
-
-    public void setRegistryInstancesList(Map<RegIdentifier, AiravataRegistry2> registryInstancesList) {
-        this.registryInstancesList = registryInstancesList;
-    }
-
-
-}

http://git-wip-us.apache.org/repos/asf/airavata/blob/0e2c10f5/modules/rest/mappings/src/main/java/org/apache/airavata/rest/mappings/utils/RegistryListener.java
----------------------------------------------------------------------
diff --git a/modules/rest/mappings/src/main/java/org/apache/airavata/rest/mappings/utils/RegistryListener.java b/modules/rest/mappings/src/main/java/org/apache/airavata/rest/mappings/utils/RegistryListener.java
deleted file mode 100644
index 74ada3f..0000000
--- a/modules/rest/mappings/src/main/java/org/apache/airavata/rest/mappings/utils/RegistryListener.java
+++ /dev/null
@@ -1,54 +0,0 @@
-/*
- *
- * 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.rest.mappings.utils;
-
-import javax.servlet.ServletContext;
-import javax.servlet.ServletContextEvent;
-import javax.servlet.ServletContextListener;
-
-import org.apache.airavata.common.utils.AiravataUtils;
-import org.apache.airavata.common.utils.ServerSettings;
-import org.apache.airavata.registry.api.Gateway;
-
-public class RegistryListener implements ServletContextListener {
-
-    public void contextInitialized(ServletContextEvent servletContextEvent) {
-        try {
-        	AiravataUtils.setExecutionAsServer();
-            ServletContext servletContext = servletContextEvent.getServletContext();
-            String gatewayID = ServerSettings.getSystemUserGateway();
-            String user = ServerSettings.getSystemUser();
-            Gateway gateway =  new Gateway(gatewayID);
-
-            servletContext.setAttribute(RestServicesConstants.GATEWAY, gateway);
-            servletContext.setAttribute(RestServicesConstants.AIRAVATA_USER, user);
-            servletContext.setAttribute(
-                    RestServicesConstants.AIRAVATA_REGISTRY_POOL,new RegistryInstancesPool(100));
-        } catch (Exception e) {
-            e.printStackTrace();
-        }
-    }
-
-    public void contextDestroyed(ServletContextEvent servletContextEvent) {
-
-    }
-}

http://git-wip-us.apache.org/repos/asf/airavata/blob/0e2c10f5/modules/rest/mappings/src/main/java/org/apache/airavata/rest/mappings/utils/ResourcePathConstants.java
----------------------------------------------------------------------
diff --git a/modules/rest/mappings/src/main/java/org/apache/airavata/rest/mappings/utils/ResourcePathConstants.java b/modules/rest/mappings/src/main/java/org/apache/airavata/rest/mappings/utils/ResourcePathConstants.java
deleted file mode 100644
index ddf9396..0000000
--- a/modules/rest/mappings/src/main/java/org/apache/airavata/rest/mappings/utils/ResourcePathConstants.java
+++ /dev/null
@@ -1,249 +0,0 @@
-/*
- *
- * 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.rest.mappings.utils;
-
-public class ResourcePathConstants {
-
-    public static final String BASE_URL = "http://localhost:8080/airavata/services/registry";
-
-    public final class ConfigResourcePathConstants {
-        public static final String CONFIGURATION_REGISTRY_RESOURCE = "/congfigregistry/";
-        public static final String GET_CONFIGURATION = "get/configuration";
-        public static final String GET_CONFIGURATION_LIST = "get/configurationlist";
-        public static final String SAVE_CONFIGURATION = "save/configuration";
-        public static final String UPDATE_CONFIGURATION = "update/configuration";
-        public static final String DELETE_ALL_CONFIGURATION = "delete/allconfiguration";
-        public static final String DELETE_CONFIGURATION ="delete/configuration";
-        public static final String GET_GFAC_URI_LIST = "get/gfac/urilist";
-        public static final String GET_WFINTERPRETER_URI_LIST = "get/workflowinterpreter/urilist";
-        public static final String GET_EVENTING_URI = "get/eventingservice/uri";
-        public static final String GET_MESSAGE_BOX_URI = "get/messagebox/uri";
-        public static final String ADD_GFAC_URI = "add/gfacuri";
-        public static final String ADD_WFINTERPRETER_URI = "add/workflowinterpreteruri";
-        public static final String ADD_EVENTING_URI = "add/eventinguri";
-        public static final String ADD_MESSAGE_BOX_URI = "add/msgboxuri";
-        public static final String ADD_GFAC_URI_DATE = "add/gfacuri/date";
-        public static final String ADD_WFINTERPRETER_URI_DATE = "add/workflowinterpreteruri/date";
-        public static final String ADD_EVENTING_URI_DATE = "add/eventinguri/date";
-        public static final String ADD_MSG_BOX_URI_DATE = "add/msgboxuri/date";
-        public static final String DELETE_GFAC_URI = "delete/gfacuri";
-        public static final String DELETE_ALL_GFAC_URIS = "delete/allgfacuris";
-        public static final String DELETE_WFINTERPRETER_URI = "delete/workflowinterpreteruri";
-        public static final String DELETE_ALL_WFINTERPRETER_URIS = "delete/allworkflowinterpreteruris";
-        public static final String DELETE_EVENTING_URI = "delete/eventinguri";
-        public static final String DELETE_MSG_BOX_URI = "delete/msgboxuri";
-    }
-
-    public final class DecResourcePathConstants {
-        public static final String DESC_RESOURCE_PATH = "/descriptorsregistry/";
-        public static final String HOST_DESC_EXISTS = "hostdescriptor/exist";
-        public static final String HOST_DESC_SAVE = "hostdescriptor/save";
-        public static final String HOST_DESC_UPDATE = "hostdescriptor/update";
-        public static final String HOST_DESC = "host/description";
-        public static final String HOST_DESC_DELETE = "hostdescriptor/delete";
-        public static final String GET_HOST_DESCS = "get/hostdescriptors";
-        public static final String GET_HOST_DESCS_NAMES = "get/hostdescriptor/names";
-        public static final String SERVICE_DESC_EXISTS = "servicedescriptor/exist";
-        public static final String SERVICE_DESC_SAVE = "servicedescriptor/save";
-        public static final String SERVICE_DESC_UPDATE = "servicedescriptor/update";
-        public static final String SERVICE_DESC = "servicedescriptor/description";
-        public static final String SERVICE_DESC_DELETE = "servicedescriptor/delete";
-        public static final String GET_SERVICE_DESCS = "get/servicedescriptors";
-        public static final String APPL_DESC_EXIST = "applicationdescriptor/exist";
-        public static final String APP_DESC_BUILD_SAVE = "applicationdescriptor/build/save";
-        public static final String APP_DESC_UPDATE = "applicationdescriptor/update";
-        public static final String APP_DESC_DESCRIPTION = "applicationdescriptor/description";
-        public static final String APP_DESC_PER_HOST_SERVICE = "applicationdescriptors/alldescriptors/host/service";
-        public static final String APP_DESC_ALL_DESCS_SERVICE = "applicationdescriptor/alldescriptors/service";
-        public static final String APP_DESC_ALL_DESCRIPTORS = "applicationdescriptor/alldescriptors";
-        public static final String APP_DESC_NAMES = "applicationdescriptor/names";
-        public static final String APP_DESC_DELETE = "applicationdescriptor/delete";
-    }
-
-    public final class ExperimentResourcePathConstants {
-        public static final String EXP_RESOURCE_PATH  =  "/experimentregistry/";
-        public static final String DELETE_EXP = "delete/experiment";
-        public static final String GET_ALL_EXPS = "get/experiments/all" ;
-        public static final String GET_EXPS_BY_PROJECT = "get/experiments/project" ;
-        public static final String GET_EXPS_BY_DATE =  "get/experiments/date";
-        public static final String GET_EXPS_PER_PROJECT_BY_DATE = "get/experiments/project/date";
-        public static final String ADD_EXP = "add/experiment" ;
-        public static final String EXP_EXISTS = "experiment/exist" ;
-        public static final String EXP_EXISTS_CREATE = "experiment/notexist/create" ;
-    }
-
-    public final class ProjectResourcePathConstants {
-        public static final String REGISTRY_API_PROJECTREGISTRY = "/projectregistry/";
-        public static final String PROJECT_EXIST = "project/exist";
-        public static final String PROJECT_EXIST_CREATE = "project/exist";
-        public static final String ADD_PROJECT = "add/project";
-        public static final String UPDATE_PROJECT = "update/project";
-        public static final String DELETE_PROJECT = "delete/project";
-        public static final String GET_PROJECT = "get/project";
-        public static final String GET_PROJECTS = "get/projects";
-    }
-
-    public final class ProvenanceResourcePathConstants {
-
-        public static final String REGISTRY_API_PROVENANCEREGISTRY = "/provenanceregistry/";
-        public static final String UPDATE_EXPERIMENT_EXECUTIONUSER = "update/experiment/executionuser";
-        public static final String GET_EXPERIMENT_EXECUTIONUSER = "get/experiment/executionuser";
-        public static final String GET_EXPERIMENT_NAME = "get/experiment/name";
-        public static final String UPDATE_EXPERIMENTNAME = "update/experimentname";
-        public static final String GET_EXPERIMENTMETADATA = "get/experimentmetadata";
-        public static final String UPDATE_EXPERIMENTMETADATA = "update/experimentmetadata";
-        public static final String GET_WORKFLOWTEMPLATENAME = "get/workflowtemplatename";
-        public static final String UPDATE_WORKFLOWINSTANCETEMPLATENAME = "update/workflowinstancetemplatename";
-        public static final String GET_EXPERIMENTWORKFLOWINSTANCES = "get/experimentworkflowinstances";
-        public static final String WORKFLOWINSTANCE_EXIST_CHECK = "workflowinstance/exist/check";
-        public static final String WORKFLOWINSTANCE_EXIST_CREATE = "workflowinstance/exist/create";
-        public static final String UPDATE_WORKFLOWINSTANCESTATUS_INSTANCEID = "update/workflowinstancestatus/instanceid";
-        public static final String UPDATE_WORKFLOWINSTANCESTATUS = "update/workflowinstancestatus";
-        public static final String GET_WORKFLOWINSTANCESTATUS = "get/workflowinstancestatus";
-        public static final String UPDATE_WORKFLOWNODEINPUT = "update/workflownodeinput";
-        public static final String UPDATE_WORKFLOWNODEOUTPUT = "update/workflownodeoutput";
-        public static final String GET_EXPERIMENT = "get/experiment";
-        public static final String GET_EXPERIMENT_ID_USER = "get/experimentId/user";
-        public static final String GET_EXPERIMENT_USER = "get/experiment/user";
-        public static final String GET_EXPERIMENTS = "get/experiments";
-        public static final String UPDATE_WORKFLOWNODE_STATUS = "update/workflownode/status";
-        public static final String GET_WORKFLOWNODE_STATUS = "get/workflownode/status";
-        public static final String GET_WORKFLOWNODE_STARTTIME = "get/workflownode/starttime";
-        public static final String GET_WORKFLOW_STARTTIME = "get/workflow/starttime";
-        public static final String UPDATE_WORKFLOWNODE_GRAMDATA = "update/workflownode/gramdata";
-        public static final String GET_WORKFLOWINSTANCEDATA = "get/workflowinstancedata";
-        public static final String WORKFLOWINSTANCE_NODE_EXIST = "wfnode/exist";
-        public static final String WORKFLOWINSTANCE_NODE_EXIST_CREATE = "wfnode/exist/create";
-        public static final String WORKFLOWINSTANCE_NODE_DATA = "workflowinstance/nodeData";
-        public static final String ADD_WORKFLOWINSTANCE = "add/workflowinstance";
-        public static final String UPDATE_WORKFLOWNODETYPE = "update/workflownodetype";
-        public static final String ADD_WORKFLOWINSTANCENODE = "add/workflowinstancenode";
-        public static final String EXPERIMENTNAME_EXISTS = "experimentname/exists";
-
-        public static final String GET_EXPERIMENT_METAINFORMATION = "get/experiment/metainformation";
-        public static final String GET_ALL_EXPERIMENT_METAINFORMATION = "get/all/experiment/metainformation";
-        public static final String SEARCH_EXPERIMENTS = "search/experiments";
-
-        public static final String GET_EXPERIMENT_ERRORS = "experiment/errors";
-        public static final String GET_WORKFLOW_ERRORS = "workflow/errors";
-        public static final String GET_NODE_ERRORS = "node/errors";
-        public static final String GET_GFAC_ERRORS = "gfac/errors";
-        public static final String GET_ALL_GFAC_ERRORS = "gfac/all/errors";
-        public static final String GET_EXECUTION_ERRORS = "execution/errors";
-        public static final String ADD_EXPERIMENT_ERROR = "add/experiment/errors";
-        public static final String ADD_WORKFLOW_ERROR = "add/workflow/errors";
-        public static final String ADD_NODE_ERROR = "add/node/errors";
-        public static final String ADD_GFAC_ERROR = "add/gfac/errors";
-        public static final String ADD_APPLICATION_JOB = "add/application/job";
-        public static final String UPDATE_APPLICATION_JOB = "update/application/job";
-        public static final String UPDATE_APPLICATION_JOB_STATUS = "update/application/jobstatus";
-        public static final String UPDATE_APPLICATION_JOB_DATA = "update/application/jobdata";
-        public static final String UPDATE_APPLICATION_JOB_SUBMITTED_TIME = "update/application/job/submit";
-        public static final String UPDATE_APPLICATION_JOB_COMPLETED_TIME = "update/application/job/complete";
-        public static final String UPDATE_APPLICATION_JOB_METADATA = "update/application/job/metadata";
-        public static final String GET_APPLICATION_JOB = "get/application/job";
-        public static final String GET_APPLICATION_JOBS_FOR_DESCRIPTORS = "get/application/jobs/descriptors";
-        public static final String GET_APPLICATION_JOBS = "get/application/jobs";
-        public static final String APPLICATION_JOB_EXIST = "application/job/exists";
-        public static final String GET_APPLICATION_JOBS_STATUS_HISTORY = "get/application/status/history";
-
-    }
-
-    public final class PublishedWFConstants {
-
-        public static final String REGISTRY_API_PUBLISHWFREGISTRY = "/publishwfregistry/";
-        public static final String PUBLISHWF_EXIST = "publishwf/exist";
-        public static final String PUBLISH_WORKFLOW = "publish/workflow";
-        public static final String PUBLISH_DEFAULT_WORKFLOW = "publish/default/workflow";
-        public static final String GET_PUBLISHWORKFLOWGRAPH = "get/publishworkflowgraph";
-        public static final String GET_PUBLISHWORKFLOWNAMES = "get/publishworkflownames";
-        public static final String GET_PUBLISHWORKFLOWS = "get/publishworkflows";
-        public static final String REMOVE_PUBLISHWORKFLOW = "remove/publishworkflow";
-    }
-
-    public final class UserWFConstants {
-
-        public static final String REGISTRY_API_USERWFREGISTRY = "/userwfregistry/";
-        public static final String WORKFLOW_EXIST = "workflow/exist";
-        public static final String ADD_WORKFLOW = "add/workflow";
-        public static final String UPDATE_WORKFLOW = "update/workflow";
-        public static final String GET_WORKFLOWGRAPH = "get/workflowgraph";
-        public static final String GET_WORKFLOWS = "get/workflows";
-        public static final String REMOVE_WORKFLOW = "remove/workflow";
-    }
-    
-    public final class CredentialResourceConstants {
-
-        public static final String REGISTRY_API_CREDENTIALREGISTRY = "/credentialregistry/";
-        public static final String SSH_CREDENTIAL = "ssh/credential";
-        public static final String SSH_CREDENTIAL_EXIST = "ssh/credential/exist";
-    }
-    
-    public final class UserResourceConstants {
-
-        public static final String REGISTRY_API_USERREGISTRY = "/userregistry/";
-        public static final String GET_ALL_USERS = "get/user/all";
-    }
-
-    public final class BasicRegistryConstants {
-
-        public static final String REGISTRY_API_BASICREGISTRY = "/basicregistry/";
-        public static final String GET_GATEWAY = "get/gateway";
-        public static final String GET_USER = "get/user";
-        public static final String SET_GATEWAY = "set/gateway";
-        public static final String SET_USER = "set/user";
-        public static final String VERSION = "get/version";
-        public static final String GET_SERVICE_URL = "get/serviceURL";
-        public static final String SET_SERVICE_URL = "set/serviceURL";
-    }
-    public final class ExperimentExecutionConstants {
-        public static final String EXP_EXEC_PATH  =  "/execution/";
-        public static final String GET_HI= "get/hi";
-        public static final String EXEC_EXPERIMENT= "workflow";
-        public static final String CANCEL_EXPERIMENT = "cancel/experiment";
-        public static final String CANCEL_WORKFLOW = "cancel/workflow";
-        public static final String CANCEL_NODE = "cancel/node";
-        public static final String SUSPEND_EXPERIMENT = "suspend/experiment";
-        public static final String RESUME_EXPERIMENT = "resume/experiment";
-    }
-    
-    public final class ServerManagerConstants{
-    	public static final String PATH="/configuration/";
-    }
-    
-    public final class ExperimentDataConstants{
-    	public static final String PATH="/data/";
-    }
-    
-    public final class ApplicationDataConstants{
-    	public static final String PATH="/application/";
-    }
-    
-    public final class WorkflowDataConstants{
-    	public static final String PATH="/workflows/";
-    }
-    
-    public final class PublishedWorkflowDataConstants{
-    	public static final String PATH="/workflows/published/";
-    }
-    
-}

http://git-wip-us.apache.org/repos/asf/airavata/blob/0e2c10f5/modules/rest/mappings/src/main/java/org/apache/airavata/rest/mappings/utils/RestServicesConstants.java
----------------------------------------------------------------------
diff --git a/modules/rest/mappings/src/main/java/org/apache/airavata/rest/mappings/utils/RestServicesConstants.java b/modules/rest/mappings/src/main/java/org/apache/airavata/rest/mappings/utils/RestServicesConstants.java
deleted file mode 100644
index a022f62..0000000
--- a/modules/rest/mappings/src/main/java/org/apache/airavata/rest/mappings/utils/RestServicesConstants.java
+++ /dev/null
@@ -1,30 +0,0 @@
-/*
- *
- * 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.rest.mappings.utils;
-
-import org.apache.commons.codec.binary.Base64;
-
-public class RestServicesConstants {
-    public static final String GATEWAY = "gateway";
-    public static final String AIRAVATA_USER = "airavataUser";
-    public static final String AIRAVATA_REGISTRY_POOL = "airavataRegistryPool";
-}

http://git-wip-us.apache.org/repos/asf/airavata/blob/0e2c10f5/modules/rest/pom.xml
----------------------------------------------------------------------
diff --git a/modules/rest/pom.xml b/modules/rest/pom.xml
deleted file mode 100644
index 4772c75..0000000
--- a/modules/rest/pom.xml
+++ /dev/null
@@ -1,44 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-
-<!--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. -->
-
-<project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/maven-v4_0_0.xsd">
-
-    <parent>
-        <groupId>org.apache.airavata</groupId>
-        <artifactId>airavata</artifactId>
-        <version>0.12-SNAPSHOT</version>
-        <relativePath>../../pom.xml</relativePath>
-    </parent>
-
-    <modelVersion>4.0.0</modelVersion>
-    <artifactId>rest</artifactId>
-    <packaging>pom</packaging>
-    <name>Airavata REST</name>
-    <url>http://airavata.apache.org/</url>
-    
-    <profiles>
-        <profile>
-            <id>default</id>
-            <activation>
-                <activeByDefault>true</activeByDefault>
-            </activation>
-            <modules>
-                <module>mappings</module>
-                <module>service</module>
-                <module>webapp</module>
-                <module>client</module>
-            </modules>
-        </profile>
-    </profiles>
-    <properties>
-        <project.build.sourceEncoding>UTF-8</project.build.sourceEncoding>
-        <project.reporting.outputEncoding>UTF-8</project.reporting.outputEncoding>
-    </properties>
-</project>

http://git-wip-us.apache.org/repos/asf/airavata/blob/0e2c10f5/modules/rest/service/pom.xml
----------------------------------------------------------------------
diff --git a/modules/rest/service/pom.xml b/modules/rest/service/pom.xml
deleted file mode 100644
index 90ebed7..0000000
--- a/modules/rest/service/pom.xml
+++ /dev/null
@@ -1,99 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-
-<!--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. -->
-
-<project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">
-	
-	<parent>
-		<groupId>org.apache.airavata</groupId>
-		<artifactId>rest</artifactId>
-		<version>0.12-SNAPSHOT</version>
-		<relativePath>../pom.xml</relativePath>
-	</parent>
-
-	<modelVersion>4.0.0</modelVersion>
-	<artifactId>airavata-rest-services</artifactId>
-	<packaging>jar</packaging>
-	<name>airavata-rest-services</name>
-
-	<dependencies>
-		<dependency>
-			<groupId>org.apache.derby</groupId>
-			<artifactId>derbyclient</artifactId>
-			<version>${derby.version}</version>
-		</dependency>
-		<dependency>
-			<groupId>com.sun.jersey.jersey-test-framework</groupId>
-			<artifactId>jersey-test-framework-grizzly2</artifactId>
-			<version>${jersey.version}</version>
-			<scope>test</scope>
-		</dependency>
-		<dependency>
-			<groupId>org.apache.shiro</groupId>
-			<artifactId>shiro-core</artifactId>
-			<version>1.2.1</version>
-		</dependency>
-
-        <dependency>
-            <groupId>de.odysseus.staxon</groupId>
-            <artifactId>staxon</artifactId>
-            <version>1.2</version>
-        </dependency>
-
-		<!-- Airavata -->
-		<dependency>
-			<groupId>org.apache.airavata</groupId>
-			<artifactId>airavata-gfac-schema-utils</artifactId>
-			<version>${project.version}</version>
-		</dependency>
-		<dependency>
-			<groupId>org.apache.airavata</groupId>
-			<artifactId>airavata-registry-api</artifactId>
-			<version>${project.version}</version>
-		</dependency>
-		<dependency>
-			<groupId>org.apache.airavata</groupId>
-			<artifactId>airavata-security</artifactId>
-			<version>${project.version}</version>
-		</dependency>
-		<!--dependency>
-			<groupId>org.apache.airavata</groupId>
-			<artifactId>airavata-jpa-registry</artifactId>
-			<version>${project.version}</version>
-		</dependency-->
-		<dependency>
-			<groupId>org.apache.airavata</groupId>
-			<artifactId>airavata-rest-mappings</artifactId>
-			<version>${project.version}</version>
-		</dependency>
-		<!-- Logging -->
-		<dependency>
-			<groupId>org.slf4j</groupId>
-			<artifactId>slf4j-api</artifactId>
-		</dependency>
-		<dependency>
-			<groupId>org.slf4j</groupId>
-			<artifactId>slf4j-simple</artifactId>
-		</dependency>
-		<dependency>
-			<groupId>org.slf4j</groupId>
-			<artifactId>jcl-over-slf4j</artifactId>
-		</dependency>
-		<dependency>
-			<groupId>org.slf4j</groupId>
-			<artifactId>slf4j-log4j12</artifactId>
-		</dependency>
-	</dependencies>
-	<properties>
-		<jersey.version>1.13</jersey.version>
-	</properties>
-</project>

http://git-wip-us.apache.org/repos/asf/airavata/blob/0e2c10f5/modules/rest/service/src/main/java/org/apache/airavata/services/experiment/ExperimentDataService.java
----------------------------------------------------------------------
diff --git a/modules/rest/service/src/main/java/org/apache/airavata/services/experiment/ExperimentDataService.java b/modules/rest/service/src/main/java/org/apache/airavata/services/experiment/ExperimentDataService.java
deleted file mode 100644
index b0d6f4b..0000000
--- a/modules/rest/service/src/main/java/org/apache/airavata/services/experiment/ExperimentDataService.java
+++ /dev/null
@@ -1,32 +0,0 @@
-/*
- *
- * 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.services.experiment;
-
-import javax.ws.rs.Path;
-
-import org.apache.airavata.rest.mappings.utils.ResourcePathConstants.ExperimentDataConstants;
-import org.apache.airavata.services.registry.rest.resources.ProvenanceRegistryResource;
-
-@Path(ExperimentDataConstants.PATH)
-public class ExperimentDataService extends ProvenanceRegistryResource{
-
-}

http://git-wip-us.apache.org/repos/asf/airavata/blob/0e2c10f5/modules/rest/service/src/main/java/org/apache/airavata/services/experiment/ExperimentExecutionService.java
----------------------------------------------------------------------
diff --git a/modules/rest/service/src/main/java/org/apache/airavata/services/experiment/ExperimentExecutionService.java b/modules/rest/service/src/main/java/org/apache/airavata/services/experiment/ExperimentExecutionService.java
deleted file mode 100644
index 5cf15f7..0000000
--- a/modules/rest/service/src/main/java/org/apache/airavata/services/experiment/ExperimentExecutionService.java
+++ /dev/null
@@ -1,115 +0,0 @@
-///*
-// *
-// * 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.services.experiment;
-//
-//import java.util.Map;
-//
-//import javax.ws.rs.Consumes;
-//import javax.ws.rs.DELETE;
-//import javax.ws.rs.GET;
-//import javax.ws.rs.POST;
-//import javax.ws.rs.Path;
-//import javax.ws.rs.Produces;
-//import javax.ws.rs.QueryParam;
-//import javax.ws.rs.core.MediaType;
-//import javax.ws.rs.core.Response;
-//
-//import org.apache.airavata.client.AiravataAPIUtils;
-//import org.apache.airavata.client.api.ExperimentAdvanceOptions;
-//import org.apache.airavata.common.context.WorkflowContext;
-//import org.apache.airavata.rest.mappings.utils.ResourcePathConstants;
-//import org.apache.airavata.services.registry.rest.utils.WebAppUtil;
-//import org.apache.airavata.xbaya.interpretor.WorkflowInterpretorSkeleton;
-//
-//@Path(ResourcePathConstants.ExperimentExecutionConstants.EXP_EXEC_PATH)
-//public class ExperimentExecutionService {
-//	private WorkflowInterpretorSkeleton interpreterService;
-//	
-//    @POST
-//    @Path(ResourcePathConstants.ExperimentExecutionConstants.EXEC_EXPERIMENT)
-//    @Consumes({MediaType.APPLICATION_JSON, MediaType.APPLICATION_XML})
-//    @Produces(MediaType.TEXT_PLAIN)
-//    public Response runExperiment(@QueryParam("workflowTemplateName") String workflowTemplateName, Map<String, String> workflowInputs, ExperimentAdvanceOptions advanceOptions){
-//    	String user =  WorkflowContext.getRequestUser();
-//        String gatewayId = WorkflowContext.getGatewayId();
-//    	try {
-//			String experimentId = getInterpreterService().setupAndLaunch(workflowTemplateName, advanceOptions.getCustomExperimentId(), gatewayId, user, workflowInputs, true, AiravataAPIUtils.createWorkflowContextHeaderBuilder(advanceOptions, advanceOptions.getExperimentExecutionUser(),user));
-//	    	Response.ResponseBuilder builder = Response.status(Response.Status.OK);
-//	        builder.entity(experimentId);
-//	        return builder.build();
-//		} catch (Exception e) {
-//			return WebAppUtil.reportInternalServerError(ResourcePathConstants.ExperimentExecutionConstants.EXEC_EXPERIMENT, e);
-//		}
-//
-//    }
-//
-//    @DELETE
-//    @Path(ResourcePathConstants.ExperimentExecutionConstants.CANCEL_EXPERIMENT)
-//    @Consumes({MediaType.APPLICATION_JSON, MediaType.APPLICATION_XML})
-//    @Produces(MediaType.TEXT_PLAIN)
-//    public Response cancelExperiment(@QueryParam("experimentId") String experimentId){
-//    	try {
-//			getInterpreterService().haltWorkflow(experimentId);
-//	    	Response.ResponseBuilder builder = Response.status(Response.Status.OK);
-//	        return builder.build();
-//		} catch (Exception e) {
-//			return WebAppUtil.reportInternalServerError(ResourcePathConstants.ExperimentExecutionConstants.CANCEL_EXPERIMENT, e);
-//		}
-//    }
-//
-//    @DELETE
-//    @Path(ResourcePathConstants.ExperimentExecutionConstants.SUSPEND_EXPERIMENT)
-//    @Consumes({MediaType.APPLICATION_JSON, MediaType.APPLICATION_XML})
-//    @Produces(MediaType.TEXT_PLAIN)
-//    public Response suspendExperiment(@QueryParam("experimentId") String experimentId){
-//    	try {
-//			getInterpreterService().suspendWorkflow(experimentId);
-//	    	Response.ResponseBuilder builder = Response.status(Response.Status.OK);
-//	        return builder.build();
-//		} catch (Exception e) {
-//			return WebAppUtil.reportInternalServerError(ResourcePathConstants.ExperimentExecutionConstants.SUSPEND_EXPERIMENT, e);
-//		}
-//    }
-//
-//    @GET
-//    @Path(ResourcePathConstants.ExperimentExecutionConstants.RESUME_EXPERIMENT)
-//    @Consumes({MediaType.APPLICATION_JSON, MediaType.APPLICATION_XML})
-//    @Produces(MediaType.TEXT_PLAIN)
-//    public Response resumeExperiment(@QueryParam("experimentId") String experimentId){
-//    	try {
-//			getInterpreterService().resumeWorkflow(experimentId);
-//	    	Response.ResponseBuilder builder = Response.status(Response.Status.OK);
-//	        return builder.build();
-//		} catch (Exception e) {
-//			return WebAppUtil.reportInternalServerError(ResourcePathConstants.ExperimentExecutionConstants.RESUME_EXPERIMENT, e);
-//		}
-//    }
-//    
-//	public WorkflowInterpretorSkeleton getInterpreterService() {
-//		if (interpreterService==null){
-//			interpreterService=new WorkflowInterpretorSkeleton();
-//		}
-//		return interpreterService;
-//	}
-//    
-//
-//}

http://git-wip-us.apache.org/repos/asf/airavata/blob/0e2c10f5/modules/rest/service/src/main/java/org/apache/airavata/services/gateway/ApplicationDataService.java
----------------------------------------------------------------------
diff --git a/modules/rest/service/src/main/java/org/apache/airavata/services/gateway/ApplicationDataService.java b/modules/rest/service/src/main/java/org/apache/airavata/services/gateway/ApplicationDataService.java
deleted file mode 100644
index 3365a69..0000000
--- a/modules/rest/service/src/main/java/org/apache/airavata/services/gateway/ApplicationDataService.java
+++ /dev/null
@@ -1,32 +0,0 @@
-/*
- *
- * 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.services.gateway;
-
-import javax.ws.rs.Path;
-
-import org.apache.airavata.rest.mappings.utils.ResourcePathConstants.ApplicationDataConstants;
-import org.apache.airavata.services.registry.rest.resources.DescriptorRegistryResource;
-
-@Path(ApplicationDataConstants.PATH)
-public class ApplicationDataService extends DescriptorRegistryResource {
-
-}

http://git-wip-us.apache.org/repos/asf/airavata/blob/0e2c10f5/modules/rest/service/src/main/java/org/apache/airavata/services/gateway/PublishedWorkflowDataService.java
----------------------------------------------------------------------
diff --git a/modules/rest/service/src/main/java/org/apache/airavata/services/gateway/PublishedWorkflowDataService.java b/modules/rest/service/src/main/java/org/apache/airavata/services/gateway/PublishedWorkflowDataService.java
deleted file mode 100644
index 2175813..0000000
--- a/modules/rest/service/src/main/java/org/apache/airavata/services/gateway/PublishedWorkflowDataService.java
+++ /dev/null
@@ -1,31 +0,0 @@
-/*
- *
- * 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.services.gateway;
-
-import javax.ws.rs.Path;
-
-import org.apache.airavata.rest.mappings.utils.ResourcePathConstants.WorkflowDataConstants;
-
-@Path(WorkflowDataConstants.PATH)
-public class PublishedWorkflowDataService {
-
-}

http://git-wip-us.apache.org/repos/asf/airavata/blob/0e2c10f5/modules/rest/service/src/main/java/org/apache/airavata/services/gateway/WorkflowDataService.java
----------------------------------------------------------------------
diff --git a/modules/rest/service/src/main/java/org/apache/airavata/services/gateway/WorkflowDataService.java b/modules/rest/service/src/main/java/org/apache/airavata/services/gateway/WorkflowDataService.java
deleted file mode 100644
index 43c167c..0000000
--- a/modules/rest/service/src/main/java/org/apache/airavata/services/gateway/WorkflowDataService.java
+++ /dev/null
@@ -1,31 +0,0 @@
-/*
- *
- * 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.services.gateway;
-
-import javax.ws.rs.Path;
-
-import org.apache.airavata.rest.mappings.utils.ResourcePathConstants.WorkflowDataConstants;
-
-@Path(WorkflowDataConstants.PATH)
-public class WorkflowDataService {
-
-}