Return-Path: X-Original-To: apmail-airavata-commits-archive@www.apache.org Delivered-To: apmail-airavata-commits-archive@www.apache.org Received: from mail.apache.org (hermes.apache.org [140.211.11.3]) by minotaur.apache.org (Postfix) with SMTP id 7C0EB18B60 for ; Thu, 4 Jun 2015 20:36:49 +0000 (UTC) Received: (qmail 23969 invoked by uid 500); 4 Jun 2015 20:36:49 -0000 Delivered-To: apmail-airavata-commits-archive@airavata.apache.org Received: (qmail 23835 invoked by uid 500); 4 Jun 2015 20:36:49 -0000 Mailing-List: contact commits-help@airavata.apache.org; run by ezmlm Precedence: bulk List-Help: List-Unsubscribe: List-Post: List-Id: Reply-To: dev@airavata.apache.org Delivered-To: mailing list commits@airavata.apache.org Received: (qmail 22591 invoked by uid 99); 4 Jun 2015 20:36:48 -0000 Received: from git1-us-west.apache.org (HELO git1-us-west.apache.org) (140.211.11.23) by apache.org (qpsmtpd/0.29) with ESMTP; Thu, 04 Jun 2015 20:36:48 +0000 Received: by git1-us-west.apache.org (ASF Mail Server at git1-us-west.apache.org, from userid 33) id 64865E10BE; Thu, 4 Jun 2015 20:36:48 +0000 (UTC) Content-Type: text/plain; charset="us-ascii" MIME-Version: 1.0 Content-Transfer-Encoding: 7bit From: shameera@apache.org To: commits@airavata.apache.org Date: Thu, 04 Jun 2015 20:37:10 -0000 Message-Id: In-Reply-To: <27990c52cdb74065a551c421d4d751d4@git.apache.org> References: <27990c52cdb74065a551c421d4d751d4@git.apache.org> X-Mailer: ASF-Git Admin Mailer Subject: [24/52] [abbrv] [partial] airavata git commit: registry refactoring http://git-wip-us.apache.org/repos/asf/airavata/blob/ec8c6202/modules/registry/experiment-catalog/src/main/resources/registry-mysql.sql ---------------------------------------------------------------------- diff --git a/modules/registry/experiment-catalog/src/main/resources/registry-mysql.sql b/modules/registry/experiment-catalog/src/main/resources/registry-mysql.sql deleted file mode 100644 index 14d7fc8..0000000 --- a/modules/registry/experiment-catalog/src/main/resources/registry-mysql.sql +++ /dev/null @@ -1,392 +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. - * - */ -CREATE TABLE GATEWAY -( - GATEWAY_ID VARCHAR(255), - GATEWAY_NAME VARCHAR(255), - DOMAIN VARCHAR(255), - EMAIL_ADDRESS VARCHAR(255), - PRIMARY KEY (GATEWAY_ID) -); - -CREATE TABLE CONFIGURATION -( - CONFIG_KEY VARCHAR(255), - CONFIG_VAL VARCHAR(255), - EXPIRE_DATE TIMESTAMP DEFAULT '0000-00-00 00:00:00', - CATEGORY_ID VARCHAR (255), - PRIMARY KEY(CONFIG_KEY, CONFIG_VAL, CATEGORY_ID) -); - -INSERT INTO CONFIGURATION (CONFIG_KEY, CONFIG_VAL, EXPIRE_DATE, CATEGORY_ID) VALUES('registry.version', '0.15', CURRENT_TIMESTAMP ,'SYSTEM'); - -CREATE TABLE USERS -( - USER_NAME VARCHAR(255), - PASSWORD VARCHAR(255), - PRIMARY KEY(USER_NAME) -); - -CREATE TABLE GATEWAY_WORKER -( - GATEWAY_ID VARCHAR(255), - USER_NAME VARCHAR(255), - PRIMARY KEY (GATEWAY_ID, USER_NAME), - FOREIGN KEY (GATEWAY_ID) REFERENCES GATEWAY(GATEWAY_ID) ON DELETE CASCADE, - FOREIGN KEY (USER_NAME) REFERENCES USERS(USER_NAME) ON DELETE CASCADE -); - -CREATE TABLE PROJECT -( - GATEWAY_ID VARCHAR(255), - USER_NAME VARCHAR(255), - PROJECT_NAME VARCHAR(255) NOT NULL, - PROJECT_ID VARCHAR(255), - DESCRIPTION VARCHAR(255), - CREATION_TIME TIMESTAMP DEFAULT NOW(), - PRIMARY KEY (PROJECT_ID), - FOREIGN KEY (GATEWAY_ID) REFERENCES GATEWAY(GATEWAY_ID) ON DELETE CASCADE, - FOREIGN KEY (USER_NAME) REFERENCES USERS(USER_NAME) ON DELETE CASCADE -); - -CREATE TABLE PROJECT_USER -( - PROJECT_ID VARCHAR(255), - USER_NAME VARCHAR(255), - PRIMARY KEY (PROJECT_ID,USER_NAME), - FOREIGN KEY (PROJECT_ID) REFERENCES PROJECT(PROJECT_ID) ON DELETE CASCADE, - FOREIGN KEY (USER_NAME) REFERENCES USERS(USER_NAME) ON DELETE CASCADE -); - -CREATE TABLE EXPERIMENT -( - EXPERIMENT_ID VARCHAR(255), - GATEWAY_ID VARCHAR(255), - EXECUTION_USER VARCHAR(255) NOT NULL, - PROJECT_ID VARCHAR(255) NOT NULL, - CREATION_TIME TIMESTAMP DEFAULT NOW(), - EXPERIMENT_NAME VARCHAR(255) NOT NULL, - EXPERIMENT_DESCRIPTION VARCHAR(255), - APPLICATION_ID VARCHAR(255), - APPLICATION_VERSION VARCHAR(255), - WORKFLOW_TEMPLATE_ID VARCHAR(255), - WORKFLOW_TEMPLATE_VERSION VARCHAR(255), - WORKFLOW_EXECUTION_ID VARCHAR(255), - ALLOW_NOTIFICATION SMALLINT, - GATEWAY_EXECUTION_ID VARCHAR(255), - PRIMARY KEY(EXPERIMENT_ID), - FOREIGN KEY (GATEWAY_ID) REFERENCES GATEWAY(GATEWAY_ID) ON DELETE CASCADE, - FOREIGN KEY (EXECUTION_USER) REFERENCES USERS(USER_NAME) ON DELETE CASCADE, - FOREIGN KEY (PROJECT_ID) REFERENCES PROJECT(PROJECT_ID) ON DELETE CASCADE -); - -CREATE TABLE EXPERIMENT_INPUT -( - EXPERIMENT_ID VARCHAR(255), - INPUT_KEY VARCHAR(255) NOT NULL, - DATA_TYPE VARCHAR(255), - APP_ARGUMENT VARCHAR(255), - STANDARD_INPUT SMALLINT, - USER_FRIENDLY_DESC VARCHAR(255), - METADATA VARCHAR(255), - VALUE LONGTEXT, - INPUT_ORDER INTEGER, - IS_REQUIRED SMALLINT, - REQUIRED_TO_COMMANDLINE SMALLINT, - DATA_STAGED SMALLINT, - PRIMARY KEY(EXPERIMENT_ID,INPUT_KEY), - FOREIGN KEY (EXPERIMENT_ID) REFERENCES EXPERIMENT(EXPERIMENT_ID) ON DELETE CASCADE -); - -CREATE TABLE EXPERIMENT_OUTPUT -( - EXPERIMENT_ID VARCHAR(255), - OUTPUT_KEY VARCHAR(255) NOT NULL, - DATA_TYPE VARCHAR(255), - VALUE LONGTEXT, - IS_REQUIRED SMALLINT, - REQUIRED_TO_COMMANDLINE SMALLINT, - DATA_MOVEMENT SMALLINT, - DATA_NAME_LOCATION VARCHAR(255), - SEARCH_QUERY VARCHAR(255), - APP_ARGUMENT VARCHAR(255), - PRIMARY KEY(EXPERIMENT_ID,OUTPUT_KEY), - FOREIGN KEY (EXPERIMENT_ID) REFERENCES EXPERIMENT(EXPERIMENT_ID) ON DELETE CASCADE -); - -CREATE TABLE WORKFLOW_NODE_DETAIL -( - EXPERIMENT_ID VARCHAR(255) NOT NULL, - NODE_INSTANCE_ID VARCHAR(255), - CREATION_TIME TIMESTAMP DEFAULT NOW(), - NODE_NAME VARCHAR(255) NOT NULL, - EXECUTION_UNIT VARCHAR(255) NOT NULL, - EXECUTION_UNIT_DATA VARCHAR(255), - PRIMARY KEY(NODE_INSTANCE_ID), - FOREIGN KEY (EXPERIMENT_ID) REFERENCES EXPERIMENT(EXPERIMENT_ID) ON DELETE CASCADE -); - -CREATE TABLE TASK_DETAIL -( - TASK_ID VARCHAR(255), - NODE_INSTANCE_ID VARCHAR(255), - CREATION_TIME TIMESTAMP DEFAULT NOW(), - APPLICATION_ID VARCHAR(255), - APPLICATION_VERSION VARCHAR(255), - APPLICATION_DEPLOYMENT_ID VARCHAR(255), - ALLOW_NOTIFICATION SMALLINT, - PRIMARY KEY(TASK_ID), - FOREIGN KEY (NODE_INSTANCE_ID) REFERENCES WORKFLOW_NODE_DETAIL(NODE_INSTANCE_ID) ON DELETE CASCADE -); - -CREATE TABLE NOTIFICATION_EMAIL -( - EMAIL_ID INTEGER NOT NULL AUTO_INCREMENT, - EXPERIMENT_ID VARCHAR(255), - TASK_ID VARCHAR(255), - EMAIL_ADDRESS VARCHAR(255), - PRIMARY KEY(EMAIL_ID), - FOREIGN KEY (EXPERIMENT_ID) REFERENCES EXPERIMENT(EXPERIMENT_ID) ON DELETE CASCADE, - FOREIGN KEY (TASK_ID) REFERENCES TASK_DETAIL(TASK_ID) ON DELETE CASCADE -); - -CREATE TABLE APPLICATION_INPUT -( - TASK_ID VARCHAR(255), - INPUT_KEY VARCHAR(255) NOT NULL, - DATA_TYPE VARCHAR(255), - APP_ARGUMENT VARCHAR(255), - STANDARD_INPUT SMALLINT, - USER_FRIENDLY_DESC VARCHAR(255), - METADATA VARCHAR(255), - VALUE LONGTEXT, - INPUT_ORDER INTEGER, - IS_REQUIRED SMALLINT, - REQUIRED_TO_COMMANDLINE SMALLINT, - DATA_STAGED SMALLINT, - PRIMARY KEY(TASK_ID,INPUT_KEY), - FOREIGN KEY (TASK_ID) REFERENCES TASK_DETAIL(TASK_ID) ON DELETE CASCADE -); - -CREATE TABLE APPLICATION_OUTPUT -( - TASK_ID VARCHAR(255), - OUTPUT_KEY VARCHAR(255) NOT NULL, - DATA_TYPE VARCHAR(255), - VALUE LONGTEXT, - DATA_MOVEMENT SMALLINT, - IS_REQUIRED SMALLINT, - REQUIRED_TO_COMMANDLINE SMALLINT, - DATA_NAME_LOCATION VARCHAR(255), - SEARCH_QUERY VARCHAR(255), - APP_ARGUMENT VARCHAR(255), - PRIMARY KEY(TASK_ID,OUTPUT_KEY), - FOREIGN KEY (TASK_ID) REFERENCES TASK_DETAIL(TASK_ID) ON DELETE CASCADE -); - -CREATE TABLE NODE_INPUT -( - NODE_INSTANCE_ID VARCHAR(255), - INPUT_KEY VARCHAR(255) NOT NULL, - DATA_TYPE VARCHAR(255), - APP_ARGUMENT VARCHAR(255), - STANDARD_INPUT SMALLINT, - USER_FRIENDLY_DESC VARCHAR(255), - METADATA VARCHAR(255), - VALUE VARCHAR(255), - INPUT_ORDER INTEGER, - IS_REQUIRED SMALLINT, - REQUIRED_TO_COMMANDLINE SMALLINT, - DATA_STAGED SMALLINT, - PRIMARY KEY(NODE_INSTANCE_ID,INPUT_KEY), - FOREIGN KEY (NODE_INSTANCE_ID) REFERENCES WORKFLOW_NODE_DETAIL(NODE_INSTANCE_ID) ON DELETE CASCADE -); - -CREATE TABLE NODE_OUTPUT -( - NODE_INSTANCE_ID VARCHAR(255), - OUTPUT_KEY VARCHAR(255) NOT NULL, - DATA_TYPE VARCHAR(255), - VALUE VARCHAR(255), - IS_REQUIRED SMALLINT, - REQUIRED_TO_COMMANDLINE SMALLINT, - DATA_MOVEMENT SMALLINT, - DATA_NAME_LOCATION VARCHAR(255), - SEARCH_QUERY VARCHAR(255), - APP_ARGUMENT VARCHAR(255), - PRIMARY KEY(NODE_INSTANCE_ID,OUTPUT_KEY), - FOREIGN KEY (NODE_INSTANCE_ID) REFERENCES WORKFLOW_NODE_DETAIL(NODE_INSTANCE_ID) ON DELETE CASCADE -); - -CREATE TABLE JOB_DETAIL -( - JOB_ID VARCHAR(255), - TASK_ID VARCHAR(255), - JOB_DESCRIPTION LONGTEXT NOT NULL, - CREATION_TIME TIMESTAMP DEFAULT NOW(), - COMPUTE_RESOURCE_CONSUMED VARCHAR(255), - JOBNAME VARCHAR (255), - WORKING_DIR VARCHAR(255), - PRIMARY KEY (TASK_ID, JOB_ID), - FOREIGN KEY (TASK_ID) REFERENCES TASK_DETAIL(TASK_ID) ON DELETE CASCADE -); - -CREATE TABLE DATA_TRANSFER_DETAIL -( - TRANSFER_ID VARCHAR(255), - TASK_ID VARCHAR(255), - CREATION_TIME TIMESTAMP DEFAULT NOW(), - TRANSFER_DESC VARCHAR(255) NOT NULL, - PRIMARY KEY(TRANSFER_ID), - FOREIGN KEY (TASK_ID) REFERENCES TASK_DETAIL(TASK_ID) ON DELETE CASCADE -); - -CREATE TABLE ERROR_DETAIL -( - ERROR_ID INTEGER NOT NULL AUTO_INCREMENT, - EXPERIMENT_ID VARCHAR(255), - TASK_ID VARCHAR(255), - NODE_INSTANCE_ID VARCHAR(255), - JOB_ID VARCHAR(255), - CREATION_TIME TIMESTAMP DEFAULT NOW(), - ACTUAL_ERROR_MESSAGE LONGTEXT, - USER_FRIEDNLY_ERROR_MSG VARCHAR(255), - TRANSIENT_OR_PERSISTENT SMALLINT, - ERROR_CATEGORY VARCHAR(255), - CORRECTIVE_ACTION VARCHAR(255), - ACTIONABLE_GROUP VARCHAR(255), - PRIMARY KEY(ERROR_ID), - FOREIGN KEY (EXPERIMENT_ID) REFERENCES EXPERIMENT(EXPERIMENT_ID) ON DELETE CASCADE, - FOREIGN KEY (TASK_ID) REFERENCES TASK_DETAIL(TASK_ID) ON DELETE CASCADE, - FOREIGN KEY (NODE_INSTANCE_ID) REFERENCES WORKFLOW_NODE_DETAIL(NODE_INSTANCE_ID) ON DELETE CASCADE -); - -CREATE TABLE STATUS -( - STATUS_ID INTEGER NOT NULL AUTO_INCREMENT, - EXPERIMENT_ID VARCHAR(255), - NODE_INSTANCE_ID VARCHAR(255), - TRANSFER_ID VARCHAR(255), - TASK_ID VARCHAR(255), - JOB_ID VARCHAR(255), - STATE VARCHAR(255), - STATUS_UPDATE_TIME TIMESTAMP DEFAULT '0000-00-00 00:00:00' ON UPDATE now(), - STATUS_TYPE VARCHAR(255), - PRIMARY KEY(STATUS_ID), - FOREIGN KEY (EXPERIMENT_ID) REFERENCES EXPERIMENT(EXPERIMENT_ID) ON DELETE CASCADE, - FOREIGN KEY (TASK_ID) REFERENCES TASK_DETAIL(TASK_ID) ON DELETE CASCADE, - FOREIGN KEY (NODE_INSTANCE_ID) REFERENCES WORKFLOW_NODE_DETAIL(NODE_INSTANCE_ID) ON DELETE CASCADE, - FOREIGN KEY (TRANSFER_ID) REFERENCES DATA_TRANSFER_DETAIL(TRANSFER_ID) ON DELETE CASCADE -); - -CREATE TABLE CONFIG_DATA -( - EXPERIMENT_ID VARCHAR(255), - AIRAVATA_AUTO_SCHEDULE SMALLINT NOT NULL, - OVERRIDE_MANUAL_SCHEDULE_PARAMS SMALLINT NOT NULL, - SHARE_EXPERIMENT SMALLINT, - USER_DN VARCHAR(255), - GENERATE_CERT SMALLINT, - PRIMARY KEY(EXPERIMENT_ID), - FOREIGN KEY (EXPERIMENT_ID) REFERENCES EXPERIMENT(EXPERIMENT_ID) ON DELETE CASCADE - -); - -CREATE TABLE COMPUTATIONAL_RESOURCE_SCHEDULING -( - RESOURCE_SCHEDULING_ID INTEGER NOT NULL AUTO_INCREMENT, - EXPERIMENT_ID VARCHAR(255), - TASK_ID VARCHAR(255), - RESOURCE_HOST_ID VARCHAR(255), - CPU_COUNT INTEGER, - NODE_COUNT INTEGER, - NO_OF_THREADS INTEGER, - QUEUE_NAME VARCHAR(255), - WALLTIME_LIMIT INTEGER, - JOB_START_TIME TIMESTAMP DEFAULT '0000-00-00 00:00:00', - TOTAL_PHYSICAL_MEMORY INTEGER, - COMPUTATIONAL_PROJECT_ACCOUNT VARCHAR(255), - CHESSIS_NAME VARCHAR(255), - PRIMARY KEY(RESOURCE_SCHEDULING_ID), - FOREIGN KEY (EXPERIMENT_ID) REFERENCES EXPERIMENT(EXPERIMENT_ID) ON DELETE CASCADE, - FOREIGN KEY (TASK_ID) REFERENCES TASK_DETAIL(TASK_ID) ON DELETE CASCADE -); - -CREATE TABLE ADVANCE_INPUT_DATA_HANDLING -( - INPUT_DATA_HANDLING_ID INTEGER NOT NULL AUTO_INCREMENT, - EXPERIMENT_ID VARCHAR(255), - TASK_ID VARCHAR(255), - WORKING_DIR_PARENT VARCHAR(255), - UNIQUE_WORKING_DIR VARCHAR(255), - STAGE_INPUT_FILES_TO_WORKING_DIR SMALLINT, - CLEAN_AFTER_JOB SMALLINT, - PRIMARY KEY(INPUT_DATA_HANDLING_ID), - FOREIGN KEY (EXPERIMENT_ID) REFERENCES EXPERIMENT(EXPERIMENT_ID) ON DELETE CASCADE, - FOREIGN KEY (TASK_ID) REFERENCES TASK_DETAIL(TASK_ID) ON DELETE CASCADE -); - -CREATE TABLE ADVANCE_OUTPUT_DATA_HANDLING -( - OUTPUT_DATA_HANDLING_ID INTEGER NOT NULL AUTO_INCREMENT, - EXPERIMENT_ID VARCHAR(255), - TASK_ID VARCHAR(255), - OUTPUT_DATA_DIR VARCHAR(255), - DATA_REG_URL VARCHAR (255), - PERSIST_OUTPUT_DATA SMALLINT, - PRIMARY KEY(OUTPUT_DATA_HANDLING_ID), - FOREIGN KEY (EXPERIMENT_ID) REFERENCES EXPERIMENT(EXPERIMENT_ID) ON DELETE CASCADE, - FOREIGN KEY (TASK_ID) REFERENCES TASK_DETAIL(TASK_ID) ON DELETE CASCADE -); - -CREATE TABLE QOS_PARAM -( - QOS_ID INTEGER NOT NULL AUTO_INCREMENT, - EXPERIMENT_ID VARCHAR(255), - TASK_ID VARCHAR(255), - START_EXECUTION_AT VARCHAR(255), - EXECUTE_BEFORE VARCHAR(255), - NO_OF_RETRIES INTEGER, - PRIMARY KEY(QOS_ID), - FOREIGN KEY (EXPERIMENT_ID) REFERENCES EXPERIMENT(EXPERIMENT_ID) ON DELETE CASCADE, - FOREIGN KEY (TASK_ID) REFERENCES TASK_DETAIL(TASK_ID) ON DELETE CASCADE -); - -CREATE TABLE COMMUNITY_USER -( - GATEWAY_ID VARCHAR(256) NOT NULL, - COMMUNITY_USER_NAME VARCHAR(256) NOT NULL, - TOKEN_ID VARCHAR(256) NOT NULL, - COMMUNITY_USER_EMAIL VARCHAR(256) NOT NULL, - PRIMARY KEY (GATEWAY_ID, COMMUNITY_USER_NAME, TOKEN_ID) -); - -CREATE TABLE CREDENTIALS -( - GATEWAY_ID VARCHAR(256) NOT NULL, - TOKEN_ID VARCHAR(256) NOT NULL, - CREDENTIAL BLOB NOT NULL, - PORTAL_USER_ID VARCHAR(256) NOT NULL, - TIME_PERSISTED TIMESTAMP DEFAULT NOW() ON UPDATE NOW(), - PRIMARY KEY (GATEWAY_ID, TOKEN_ID) -); - - http://git-wip-us.apache.org/repos/asf/airavata/blob/ec8c6202/modules/registry/experiment-catalog/src/test/java/org/apache/airavata/experiment/catalog/AbstractResourceTest.java ---------------------------------------------------------------------- diff --git a/modules/registry/experiment-catalog/src/test/java/org/apache/airavata/experiment/catalog/AbstractResourceTest.java b/modules/registry/experiment-catalog/src/test/java/org/apache/airavata/experiment/catalog/AbstractResourceTest.java deleted file mode 100644 index 021ff1a..0000000 --- a/modules/registry/experiment-catalog/src/test/java/org/apache/airavata/experiment/catalog/AbstractResourceTest.java +++ /dev/null @@ -1,91 +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.experiment.catalog; - -import org.apache.airavata.common.utils.ServerSettings; -import org.apache.airavata.experiment.catalog.resources.GatewayResource; -import org.apache.airavata.experiment.catalog.resources.ProjectResource; -import org.apache.airavata.experiment.catalog.resources.UserResource; -import org.apache.airavata.experiment.catalog.resources.WorkerResource; -import org.apache.airavata.experiment.catalog.util.Initialize; -import org.junit.AfterClass; -import org.junit.Before; -import org.junit.BeforeClass; - -import java.sql.Timestamp; -import java.util.Calendar; - -public abstract class AbstractResourceTest { - - private GatewayResource gatewayResource; - private WorkerResource workerResource; - private UserResource userResource; - private ProjectResource projectResource; - - private static Initialize initialize; - - @BeforeClass - public static void setUpBeforeClass() throws Exception { - initialize = new Initialize("registry-derby.sql"); - initialize.initializeDB(); - } - @Before - public void setUp() throws Exception { - gatewayResource = (GatewayResource) ResourceUtils.getGateway(ServerSettings.getDefaultUserGateway()); - workerResource = (WorkerResource)ResourceUtils.getWorker(gatewayResource.getGatewayName(), ServerSettings.getDefaultUser()); - userResource = (UserResource)ResourceUtils.getUser(ServerSettings.getDefaultUser()); - projectResource = workerResource.getProject("default"); - } - - public Timestamp getCurrentTimestamp() { - Calendar calender = Calendar.getInstance(); - java.util.Date d = calender.getTime(); - return new Timestamp(d.getTime()); - } - @AfterClass - public static void tearDownAfterClass() throws Exception { - initialize.stopDerbyServer(); - } - - - public GatewayResource getGatewayResource() { - return gatewayResource; - } - - public WorkerResource getWorkerResource() { - return workerResource; - } - - public UserResource getUserResource() { - return userResource; - } - - public ProjectResource getProjectResource() { - return projectResource; - } - - public void setProjectResource(ProjectResource projectResource) { - this.projectResource = projectResource; - } - - -} http://git-wip-us.apache.org/repos/asf/airavata/blob/ec8c6202/modules/registry/experiment-catalog/src/test/java/org/apache/airavata/experiment/catalog/ComputationalSchedulingTest.java ---------------------------------------------------------------------- diff --git a/modules/registry/experiment-catalog/src/test/java/org/apache/airavata/experiment/catalog/ComputationalSchedulingTest.java b/modules/registry/experiment-catalog/src/test/java/org/apache/airavata/experiment/catalog/ComputationalSchedulingTest.java deleted file mode 100644 index 3f0115a..0000000 --- a/modules/registry/experiment-catalog/src/test/java/org/apache/airavata/experiment/catalog/ComputationalSchedulingTest.java +++ /dev/null @@ -1,84 +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.experiment.catalog; - -import org.apache.airavata.experiment.catalog.resources.ComputationSchedulingResource; -import org.apache.airavata.experiment.catalog.resources.ExperimentResource; -import org.junit.After; -import org.junit.Before; -import org.junit.Test; - -import java.sql.Timestamp; -import java.util.Date; - -import static org.junit.Assert.assertFalse; -import static org.junit.Assert.assertNotNull; -import static org.junit.Assert.assertTrue; - -public class ComputationalSchedulingTest extends AbstractResourceTest { - private ExperimentResource experimentResource; - private ComputationSchedulingResource schedulingResource; - private String experimentID = "testExpID"; - - @Override - @Before - public void setUp() throws Exception { - super.setUp(); - experimentResource = (ExperimentResource) getGatewayResource().create(ResourceType.EXPERIMENT); - experimentResource.setExpID(experimentID); - experimentResource.setExecutionUser(getWorkerResource().getUser()); - experimentResource.setProjectId(getProjectResource().getId()); - Timestamp currentDate = new Timestamp(new Date().getTime()); - experimentResource.setCreationTime(currentDate); - experimentResource.setApplicationId("testApplication"); - experimentResource.setApplicationVersion("1.0"); - experimentResource.setDescription("Test Application"); - experimentResource.setExpName("TestExperiment"); - experimentResource.save(); - - schedulingResource = (ComputationSchedulingResource)experimentResource.create(ResourceType.COMPUTATIONAL_RESOURCE_SCHEDULING); - schedulingResource.setResourceHostId("testResource"); - schedulingResource.setCpuCount(10); - schedulingResource.setNodeCount(5); - schedulingResource.setPhysicalMemory(1000); - schedulingResource.setProjectName("project1"); - schedulingResource.setQueueName("testQueue"); - schedulingResource.save(); - System.out.println("scheduling id : " + schedulingResource.getSchedulingId()); - } - - - @Test - public void testSave() throws Exception { - assertTrue("Computational schedule successfully", experimentResource.isExists(ResourceType.COMPUTATIONAL_RESOURCE_SCHEDULING, experimentID)); - } - - @Test - public void testRemove() throws Exception { - experimentResource.remove(ResourceType.COMPUTATIONAL_RESOURCE_SCHEDULING, experimentID); - assertFalse("Computational schedule removed successfully", experimentResource.isExists(ResourceType.COMPUTATIONAL_RESOURCE_SCHEDULING, experimentID)); - } - - @After - public void tearDown() throws Exception { - } -} http://git-wip-us.apache.org/repos/asf/airavata/blob/ec8c6202/modules/registry/experiment-catalog/src/test/java/org/apache/airavata/experiment/catalog/ConfigurationResourceTest.java ---------------------------------------------------------------------- diff --git a/modules/registry/experiment-catalog/src/test/java/org/apache/airavata/experiment/catalog/ConfigurationResourceTest.java b/modules/registry/experiment-catalog/src/test/java/org/apache/airavata/experiment/catalog/ConfigurationResourceTest.java deleted file mode 100644 index 66f025e..0000000 --- a/modules/registry/experiment-catalog/src/test/java/org/apache/airavata/experiment/catalog/ConfigurationResourceTest.java +++ /dev/null @@ -1,58 +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.experiment.catalog; - -import static org.junit.Assert.*; - -import org.apache.airavata.experiment.catalog.resources.ConfigurationResource; -import org.junit.After; -import org.junit.Test; - -import java.sql.Timestamp; -import java.util.Calendar; - -public class ConfigurationResourceTest extends AbstractResourceTest { - - @Override - public void setUp() throws Exception { - super.setUp(); - } - @Test - public void testSave() throws Exception { - ConfigurationResource configuration = ResourceUtils.createConfiguration("testConfigKey"); - configuration.setConfigVal("testConfigValue"); - Calendar calender = Calendar.getInstance(); - java.util.Date d = calender.getTime(); - Timestamp currentTime = new Timestamp(d.getTime()); - configuration.setExpireDate(currentTime); - configuration.setCategoryID("SYSTEM"); - configuration.save(); - - assertTrue("Configuration Save succuessful", ResourceUtils.isConfigurationExist("testConfigKey")); - //remove test configuration - ResourceUtils.removeConfiguration("testConfigKey"); - } - - @After - public void tearDown() throws Exception { - } -} http://git-wip-us.apache.org/repos/asf/airavata/blob/ec8c6202/modules/registry/experiment-catalog/src/test/java/org/apache/airavata/experiment/catalog/ExecutionErrorResourceTest.java ---------------------------------------------------------------------- diff --git a/modules/registry/experiment-catalog/src/test/java/org/apache/airavata/experiment/catalog/ExecutionErrorResourceTest.java b/modules/registry/experiment-catalog/src/test/java/org/apache/airavata/experiment/catalog/ExecutionErrorResourceTest.java deleted file mode 100644 index b61a16c..0000000 --- a/modules/registry/experiment-catalog/src/test/java/org/apache/airavata/experiment/catalog/ExecutionErrorResourceTest.java +++ /dev/null @@ -1,95 +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.experiment.registry.jpa; -// -//import org.apache.airavata.experiment.registry.jpa.resources.*; -// -//import java.sql.Timestamp; -//import java.util.Calendar; -// -//public class ExecutionErrorResourceTest extends AbstractResourceTest { -// private WorkflowDataResource workflowDataResource; -// private NodeDataResource nodeDataResource; -// private ExperimentMetadataResource experimentResource; -// -// @Override -// public void setUp() throws Exception { -// super.setUp(); -// GatewayResource gatewayResource = super.getGatewayResource(); -// WorkerResource workerResource = super.getWorkerResource(); -// -// ProjectResource project = new ProjectResource(workerResource, gatewayResource, "testProject"); -// project.save(); -// -// experimentResource = (ExperimentMetadataResource) gatewayResource.create(ResourceType.EXPERIMENT_METADATA); -// experimentResource.setExpID("testExpID"); -// experimentResource.setExecutionUser(workerResource.getUser()); -// -// experimentResource.setProject(project); -// experimentResource.setDescription("testDescription"); -// experimentResource.setExperimentName("textExpID"); -// experimentResource.setSubmittedDate(getCurrentTimestamp()); -// experimentResource.setShareExp(true); -// experimentResource.save(); -// -// workflowDataResource = (WorkflowDataResource) experimentResource.create(ResourceType.WORKFLOW_DATA); -// workflowDataResource.setWorkflowInstanceID("testWFInstance"); -// workflowDataResource.setTemplateName("testTemplate"); -// workflowDataResource.setExperimentID("testExpID"); -// Timestamp timestamp = getCurrentTimestamp(); -// workflowDataResource.setLastUpdatedTime(timestamp); -// workflowDataResource.save(); -// -// nodeDataResource = workflowDataResource.createNodeData("testNodeID"); -// nodeDataResource.setWorkflowDataResource(workflowDataResource); -// nodeDataResource.setInputs("testInput"); -// nodeDataResource.setOutputs("testOutput"); -// nodeDataResource.setStatus("testStatus"); -// nodeDataResource.save(); -// } -// -// -// public void testSave() throws Exception { -// ExecutionErrorResource executionErrorResource = (ExecutionErrorResource) workflowDataResource.create(ResourceType.EXECUTION_ERROR); -// executionErrorResource.setErrorCode("testErrorCode"); -// executionErrorResource.setActionTaken("testAction"); -// executionErrorResource.setErrorLocation("testErrorLocation"); -// executionErrorResource.setErrorReference(0); -// executionErrorResource.setWorkflowDataResource(workflowDataResource); -// -// executionErrorResource.setMetadataResource(experimentResource); -// executionErrorResource.setNodeID(nodeDataResource.getNodeID()); -// executionErrorResource.setGfacJobID("testGfacJobID"); -// executionErrorResource.setErrorDes("testDes"); -// executionErrorResource.setErrorMsg("errorMsg"); -// executionErrorResource.save(); -// System.out.println(executionErrorResource.getErrorID()); -// -// assertTrue("Execution Error saved successfully", workflowDataResource.isExists(ResourceType.EXECUTION_ERROR, executionErrorResource.getErrorID())); -// -// } -// -// @Override -// public void tearDown() throws Exception { -// super.tearDown(); -// } -//} http://git-wip-us.apache.org/repos/asf/airavata/blob/ec8c6202/modules/registry/experiment-catalog/src/test/java/org/apache/airavata/experiment/catalog/ExperimentDataResourceTest.java ---------------------------------------------------------------------- diff --git a/modules/registry/experiment-catalog/src/test/java/org/apache/airavata/experiment/catalog/ExperimentDataResourceTest.java b/modules/registry/experiment-catalog/src/test/java/org/apache/airavata/experiment/catalog/ExperimentDataResourceTest.java deleted file mode 100644 index 1df8091..0000000 --- a/modules/registry/experiment-catalog/src/test/java/org/apache/airavata/experiment/catalog/ExperimentDataResourceTest.java +++ /dev/null @@ -1,107 +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.experiment.registry.jpa; -// -//import org.apache.airavata.experiment.registry.jpa.resources.*; -// -//import java.sql.Timestamp; -//import java.util.Calendar; -// -//public class ExperimentDataResourceTest extends AbstractResourceTest { -// private ExperimentDataResource experimentDataResource; -// private ExperimentResource experimentResource; -// private WorkflowDataResource workflowDataResource; -// private ExperimentMetadataResource experimentMetadataResource; -// -// @Override -// public void setUp() throws Exception { -// super.setUp(); -// GatewayResource gatewayResource = super.getGatewayResource(); -// WorkerResource workerResource = super.getWorkerResource(); -// -// experimentResource = (ExperimentResource) gatewayResource.create(ResourceType.EXPERIMENT); -// experimentResource.setExpID("testExpID"); -// experimentResource.setWorker(workerResource); -// experimentResource.setProject(new ProjectResource(workerResource, gatewayResource, "testProject")); -// experimentResource.save(); -// -// experimentDataResource = (ExperimentDataResource) experimentResource.create(ResourceType.EXPERIMENT_DATA); -// experimentDataResource.setExpName("testExpID"); -// experimentDataResource.setUserName(workerResource.getUser()); -// experimentDataResource.save(); -// -// experimentMetadataResource = experimentDataResource.createExperimentMetadata(); -// workflowDataResource = experimentDataResource.createWorkflowInstanceResource("testWorkflowInstance"); -// -// experimentMetadataResource.setExpID("testExpID"); -// experimentMetadataResource.setMetadata("testMetadata"); -// experimentMetadataResource.save(); -// -// workflowDataResource.setExperimentID("testExpID"); -// workflowDataResource.setStatus("testStatus"); -// workflowDataResource.setTemplateName("testWorkflowInstance"); -// -// Calendar calender = Calendar.getInstance(); -// java.util.Date d = calender.getTime(); -// Timestamp currentTime = new Timestamp(d.getTime()); -// -// workflowDataResource.setLastUpdatedTime(currentTime); -// workflowDataResource.setStartTime(currentTime); -// workflowDataResource.save(); -// } -// -// public void testCreate() throws Exception { -// assertNotNull("workflowdata resource created", workflowDataResource); -// assertNotNull("experimemt metadata resource created", experimentMetadataResource); -// } -// -// public void testGet() throws Exception { -// assertNotNull("workflow data retrieved successfully", experimentDataResource.getWorkflowInstance("testWorkflowInstance")); -// assertNotNull("experiment meta data retrieved successfully", experimentDataResource.getExperimentMetadata()); -// } -// -// public void testGetList() throws Exception { -// assertNotNull("workflow data retrieved successfully", experimentDataResource.get(ResourceType.WORKFLOW_DATA)); -// assertNotNull("experiment meta data retrieved successfully", experimentDataResource.get(ResourceType.EXPERIMENT_METADATA)); -// } -// -// public void testSave() throws Exception { -// experimentDataResource.save(); -// assertTrue("experiment data saved successfully", experimentResource.isExists(ResourceType.EXPERIMENT_DATA, "testExpID")); -// } -// -// public void testRemove() throws Exception { -// experimentDataResource.remove(ResourceType.WORKFLOW_DATA, "testWFInstanceID"); -// assertTrue("workflow data resource removed successfully", !experimentResource.isExists(ResourceType.EXPERIMENT_DATA, "testWFInstanceID")); -// -// experimentDataResource.remove(ResourceType.EXPERIMENT_METADATA, "testExpID"); -// assertTrue("experiment meta data resource removed successfully", !experimentDataResource.isExists(ResourceType.EXPERIMENT_METADATA, "testExpID")); -// -// } -// -// @Override -// public void tearDown() throws Exception { -// super.tearDown(); -// } -// -// -//} http://git-wip-us.apache.org/repos/asf/airavata/blob/ec8c6202/modules/registry/experiment-catalog/src/test/java/org/apache/airavata/experiment/catalog/ExperimentInputResourceTest.java ---------------------------------------------------------------------- diff --git a/modules/registry/experiment-catalog/src/test/java/org/apache/airavata/experiment/catalog/ExperimentInputResourceTest.java b/modules/registry/experiment-catalog/src/test/java/org/apache/airavata/experiment/catalog/ExperimentInputResourceTest.java deleted file mode 100644 index 5372877..0000000 --- a/modules/registry/experiment-catalog/src/test/java/org/apache/airavata/experiment/catalog/ExperimentInputResourceTest.java +++ /dev/null @@ -1,75 +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.experiment.catalog; - -import org.apache.airavata.experiment.catalog.resources.*; -import org.junit.After; -import org.junit.Test; - -import java.util.List; - -import static org.junit.Assert.assertTrue; - - -public class ExperimentInputResourceTest extends AbstractResourceTest { - private ExperimentResource experimentResource; - private String experimentID = "testExpID"; - ExperimentInputResource experimentInputResource; - - @Override - public void setUp() throws Exception { - super.setUp(); - experimentResource = (ExperimentResource) getGatewayResource().create(ResourceType.EXPERIMENT); - experimentResource.setExpID(experimentID); - experimentResource.setExecutionUser(getWorkerResource().getUser()); - experimentResource.setProjectId(getProjectResource().getId()); - experimentResource.setCreationTime(getCurrentTimestamp()); - experimentResource.setApplicationId("testApplication"); - experimentResource.setApplicationVersion("1.0"); - experimentResource.setDescription("Test Application"); - experimentResource.setExpName("TestExperiment"); - experimentResource.save(); - - experimentInputResource = (ExperimentInputResource)experimentResource.create(ResourceType.EXPERIMENT_INPUT); - experimentInputResource.setExperimentId(experimentID); - experimentInputResource.setExperimentKey("testKey"); - experimentInputResource.setValue("testValue"); - experimentInputResource.setDataType("string"); - experimentInputResource.save(); - } - - @Test - public void testSave() throws Exception { - assertTrue("Experiment Input saved successfully", experimentResource.isExists(ResourceType.EXPERIMENT_INPUT, experimentID)); - } - - @After - public void tearDown() throws Exception { - } - - @Test - public void testGet () throws Exception { - List experimentInputs = experimentResource.getExperimentInputs(); - System.out.println("input counts : " + experimentInputs.size()); - assertTrue("Experiment input retrieved successfully...", experimentInputs.size() > 0); - } -} http://git-wip-us.apache.org/repos/asf/airavata/blob/ec8c6202/modules/registry/experiment-catalog/src/test/java/org/apache/airavata/experiment/catalog/ExperimentMetadataResourceTest.java ---------------------------------------------------------------------- diff --git a/modules/registry/experiment-catalog/src/test/java/org/apache/airavata/experiment/catalog/ExperimentMetadataResourceTest.java b/modules/registry/experiment-catalog/src/test/java/org/apache/airavata/experiment/catalog/ExperimentMetadataResourceTest.java deleted file mode 100644 index 86ca3d6..0000000 --- a/modules/registry/experiment-catalog/src/test/java/org/apache/airavata/experiment/catalog/ExperimentMetadataResourceTest.java +++ /dev/null @@ -1,87 +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.experiment.registry.jpa; -// -// -//import org.apache.airavata.experiment.registry.jpa.resources.*; -// -//import java.sql.Date; -//import java.sql.Timestamp; -//import java.util.Calendar; -// -//public class ExperimentMetadataResourceTest extends AbstractResourceTest { -// -// private GatewayResource gatewayResource; -// private WorkflowDataResource workflowDataResource; -// private ExperimentMetadataResource experimentResource; -// -// @Override -// public void setUp() throws Exception { -// super.setUp(); -// gatewayResource = super.getGatewayResource(); -// WorkerResource workerResource = super.getWorkerResource(); -// experimentResource = (ExperimentMetadataResource) gatewayResource.create(ResourceType.EXPERIMENT_METADATA); -// experimentResource.setExpID("testExpID"); -// experimentResource.setExecutionUser("admin"); -// experimentResource.setProject(new ProjectResource(workerResource, gatewayResource, "testProject")); -// experimentResource.setDescription("testDescription"); -// experimentResource.setExperimentName("textExpID"); -// experimentResource.setSubmittedDate(getCurrentTimestamp()); -// experimentResource.setShareExp(true); -// experimentResource.save(); -// -// ExperimentConfigDataResource exConfig = (ExperimentConfigDataResource)experimentResource.create(ResourceType.EXPERIMENT_CONFIG_DATA); -// exConfig.setExpID("testExpID"); -// exConfig.setNodeCount(5); -// exConfig.setCpuCount(10); -// exConfig.setApplicationID("testApp"); -// exConfig.setApplicationVersion("testAppVersion"); -// exConfig.save(); -// -// workflowDataResource = experimentResource.createWorkflowInstanceResource("testWFInstance"); -// workflowDataResource.setExperimentID("testExpID"); -// workflowDataResource.setStatus("testStatus"); -// workflowDataResource.setTemplateName("testWFInstance"); -// workflowDataResource.setLastUpdatedTime(getCurrentTimestamp()); -// workflowDataResource.setStartTime(getCurrentTimestamp()); -// workflowDataResource.save(); -// } -// -// public void testSave() throws Exception { -// assertTrue("experiment meta data saved successfully", gatewayResource.isExists(ResourceType.EXPERIMENT_METADATA, "testExpID")); -// -// } -// -// public void testRemove() throws Exception { -// experimentResource.remove(ResourceType.WORKFLOW_DATA, "testWFInstance"); -// assertTrue("workflow data resource removed successfully", !experimentResource.isExists(ResourceType.WORKFLOW_DATA, "testWFInstance")); -// } -// -// public void testGet() throws Exception { -// assertNotNull("experiment configuration retrieved successfully...", experimentResource.get(ResourceType.EXPERIMENT_CONFIG_DATA, "testExpID")); -// } -// -// @Override -// public void tearDown() throws Exception { -// super.tearDown(); -// } -//} http://git-wip-us.apache.org/repos/asf/airavata/blob/ec8c6202/modules/registry/experiment-catalog/src/test/java/org/apache/airavata/experiment/catalog/ExperimentOutputResourceTest.java ---------------------------------------------------------------------- diff --git a/modules/registry/experiment-catalog/src/test/java/org/apache/airavata/experiment/catalog/ExperimentOutputResourceTest.java b/modules/registry/experiment-catalog/src/test/java/org/apache/airavata/experiment/catalog/ExperimentOutputResourceTest.java deleted file mode 100644 index 605b0ae..0000000 --- a/modules/registry/experiment-catalog/src/test/java/org/apache/airavata/experiment/catalog/ExperimentOutputResourceTest.java +++ /dev/null @@ -1,76 +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.experiment.catalog; - -import org.apache.airavata.experiment.catalog.resources.ExperimentOutputResource; -import org.apache.airavata.experiment.catalog.resources.ExperimentResource; -import org.junit.After; -import org.junit.Test; - -import java.util.List; - -import static org.junit.Assert.assertTrue; - - -public class ExperimentOutputResourceTest extends AbstractResourceTest { - private ExperimentResource experimentResource; - private String experimentID = "testExpID"; - ExperimentOutputResource outputResource; - - @Override - public void setUp() throws Exception { - super.setUp(); - experimentResource = (ExperimentResource) getGatewayResource().create(ResourceType.EXPERIMENT); - experimentResource.setExpID(experimentID); - experimentResource.setExecutionUser(getWorkerResource().getUser()); - experimentResource.setProjectId(getProjectResource().getId()); - experimentResource.setCreationTime(getCurrentTimestamp()); - experimentResource.setApplicationId("testApplication"); - experimentResource.setApplicationVersion("1.0"); - experimentResource.setDescription("Test Application"); - experimentResource.setExpName("TestExperiment"); - experimentResource.save(); - - outputResource = (ExperimentOutputResource)experimentResource.create(ResourceType.EXPERIMENT_OUTPUT); - outputResource.setExperimentId(experimentResource.getExpID()); - outputResource.setExperimentKey("testKey"); - outputResource.setValue("testValue"); - outputResource.setDataType("string"); - outputResource.save(); - } - - @Test - public void testSave() throws Exception { - assertTrue("Experiment output saved successfully", experimentResource.isExists(ResourceType.EXPERIMENT_OUTPUT, experimentID)); - } - - @After - public void tearDown() throws Exception { - } - - @Test - public void testGet () throws Exception { - List outputs = experimentResource.getExperimentOutputs(); - System.out.println("output counts : " + outputs.size()); - assertTrue("Experiment output retrieved successfully...", outputs.size() > 0); - } -} http://git-wip-us.apache.org/repos/asf/airavata/blob/ec8c6202/modules/registry/experiment-catalog/src/test/java/org/apache/airavata/experiment/catalog/ExperimentResourceTest.java ---------------------------------------------------------------------- diff --git a/modules/registry/experiment-catalog/src/test/java/org/apache/airavata/experiment/catalog/ExperimentResourceTest.java b/modules/registry/experiment-catalog/src/test/java/org/apache/airavata/experiment/catalog/ExperimentResourceTest.java deleted file mode 100644 index ac39f41..0000000 --- a/modules/registry/experiment-catalog/src/test/java/org/apache/airavata/experiment/catalog/ExperimentResourceTest.java +++ /dev/null @@ -1,77 +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.experiment.catalog; - -import static org.junit.Assert.*; - -import java.sql.Timestamp; -import java.util.Date; - -import org.apache.airavata.experiment.catalog.resources.ExperimentResource; -import org.junit.After; -import org.junit.Test; - -public class ExperimentResourceTest extends AbstractResourceTest { - private ExperimentResource experimentResource; - private String experimentID = "testExpID"; - - @Override - public void setUp() throws Exception { - super.setUp(); - experimentResource = (ExperimentResource) getGatewayResource().create(ResourceType.EXPERIMENT); - experimentResource.setExpID(experimentID); - experimentResource.setExecutionUser(getWorkerResource().getUser()); - experimentResource.setProjectId(getProjectResource().getId()); - Timestamp currentDate = new Timestamp(new Date().getTime()); - experimentResource.setCreationTime(currentDate); - experimentResource.setApplicationId("testApplication"); - experimentResource.setApplicationVersion("1.0"); - experimentResource.setDescription("Test Application"); - experimentResource.setExpName("TestExperiment"); - experimentResource.save(); - } - - @Test - public void testCreate() throws Exception { - assertNotNull("experiment data resource has being created ", experimentResource); - } - - @Test - public void testSave() throws Exception { - assertTrue("experiment save successfully", getGatewayResource().isExists(ResourceType.EXPERIMENT, experimentID)); - } - - @Test - public void testGet() throws Exception { - assertNotNull("experiment data retrieved successfully", getGatewayResource().get(ResourceType.EXPERIMENT, experimentID)); - } - - @Test - public void testRemove() throws Exception { - getGatewayResource().remove(ResourceType.EXPERIMENT, experimentID); - assertFalse("experiment data removed successfully", getGatewayResource().isExists(ResourceType.EXPERIMENT, experimentID)); - } - - @After - public void tearDown() throws Exception { - } -} http://git-wip-us.apache.org/repos/asf/airavata/blob/ec8c6202/modules/registry/experiment-catalog/src/test/java/org/apache/airavata/experiment/catalog/GFacJobDataResourceTest.java ---------------------------------------------------------------------- diff --git a/modules/registry/experiment-catalog/src/test/java/org/apache/airavata/experiment/catalog/GFacJobDataResourceTest.java b/modules/registry/experiment-catalog/src/test/java/org/apache/airavata/experiment/catalog/GFacJobDataResourceTest.java deleted file mode 100644 index c546aca..0000000 --- a/modules/registry/experiment-catalog/src/test/java/org/apache/airavata/experiment/catalog/GFacJobDataResourceTest.java +++ /dev/null @@ -1,77 +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.experiment.registry.jpa; -// -//import org.apache.airavata.experiment.registry.jpa.resources.*; -// -//import java.sql.Timestamp; -//import java.util.Calendar; -// -//public class GFacJobDataResourceTest extends AbstractResourceTest { -// private WorkerResource workerResource; -// private WorkflowDataResource workflowDataResource; -// private ExperimentMetadataResource experimentResource; -// -// @Override -// public void setUp() throws Exception { -// super.setUp(); -// GatewayResource gatewayResource = super.getGatewayResource(); -// workerResource = super.getWorkerResource(); -// -// experimentResource = (ExperimentMetadataResource) gatewayResource.create(ResourceType.EXPERIMENT_METADATA); -// experimentResource.setExpID("testExpID"); -// experimentResource.setExperimentName("testExpID"); -// experimentResource.setExecutionUser(workerResource.getUser()); -// experimentResource.setProject(new ProjectResource(workerResource, gatewayResource, "testProject")); -// experimentResource.save(); -// -// workflowDataResource = (WorkflowDataResource) experimentResource.create(ResourceType.WORKFLOW_DATA); -// workflowDataResource.setWorkflowInstanceID("testWFInstance"); -// workflowDataResource.setTemplateName("testTemplate"); -// workflowDataResource.setExperimentID("testExpID"); -// Calendar calender = Calendar.getInstance(); -// java.util.Date d = calender.getTime(); -// Timestamp timestamp = new Timestamp(d.getTime()); -// workflowDataResource.setLastUpdatedTime(timestamp); -// workflowDataResource.save(); -// } -// -// @Override -// public void tearDown() throws Exception { -// super.tearDown(); -// } -// -// public void testSave() throws Exception { -// GFacJobDataResource resource = (GFacJobDataResource)workflowDataResource.create(ResourceType.GFAC_JOB_DATA); -// resource.setLocalJobID("testJobID"); -// resource.setApplicationDescID("testApplication"); -// resource.setMetadataResource(experimentResource); -// resource.setNodeID("testNode"); -// resource.setHostDescID("testHost"); -// resource.setServiceDescID("testService"); -// resource.setStatus("testStatus"); -// resource.setJobData("testJobData"); -// resource.save(); -// assertTrue("GFac job data saved successfully", workerResource.isGFacJobExists("testJobID")); -//// workflowDataResource.remove(ResourceType.GFAC_JOB_DATA, "testJobID"); -// } -//} http://git-wip-us.apache.org/repos/asf/airavata/blob/ec8c6202/modules/registry/experiment-catalog/src/test/java/org/apache/airavata/experiment/catalog/GFacJobStatusResourceTest.java ---------------------------------------------------------------------- diff --git a/modules/registry/experiment-catalog/src/test/java/org/apache/airavata/experiment/catalog/GFacJobStatusResourceTest.java b/modules/registry/experiment-catalog/src/test/java/org/apache/airavata/experiment/catalog/GFacJobStatusResourceTest.java deleted file mode 100644 index 9cf648e..0000000 --- a/modules/registry/experiment-catalog/src/test/java/org/apache/airavata/experiment/catalog/GFacJobStatusResourceTest.java +++ /dev/null @@ -1,87 +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.experiment.registry.jpa; -// -//import org.apache.airavata.experiment.registry.jpa.resources.*; -// -//import java.sql.Timestamp; -//import java.util.Calendar; -//import java.util.List; -// -//public class GFacJobStatusResourceTest extends AbstractResourceTest { -// private GFacJobDataResource gFacJobDataResource; -// -// @Override -// public void setUp() throws Exception { -// super.setUp(); -// GatewayResource gatewayResource = super.getGatewayResource(); -// WorkerResource workerResource = super.getWorkerResource(); -// -// ExperimentMetadataResource experimentResource = (ExperimentMetadataResource) gatewayResource.create(ResourceType.EXPERIMENT_METADATA); -// experimentResource.setExpID("testExpID"); -// experimentResource.setExperimentName("testExpID"); -// experimentResource.setExecutionUser(workerResource.getUser()); -// experimentResource.setProject(new ProjectResource(workerResource, gatewayResource, "testProject")); -// experimentResource.save(); -// -// -// WorkflowDataResource workflowDataResource = (WorkflowDataResource) experimentResource.create(ResourceType.WORKFLOW_DATA); -// workflowDataResource.setWorkflowInstanceID("testWFInstance"); -// workflowDataResource.setTemplateName("testTemplate"); -// workflowDataResource.setExperimentID("testExpID"); -// Calendar calender = Calendar.getInstance(); -// java.util.Date d = calender.getTime(); -// Timestamp timestamp = new Timestamp(d.getTime()); -// workflowDataResource.setLastUpdatedTime(timestamp); -// workflowDataResource.save(); -// -// gFacJobDataResource = (GFacJobDataResource) workflowDataResource.create(ResourceType.GFAC_JOB_DATA); -// gFacJobDataResource.setLocalJobID("testJobID"); -// gFacJobDataResource.setApplicationDescID("testApplication"); -// gFacJobDataResource.setMetadataResource(experimentResource); -// gFacJobDataResource.setNodeID("testNode"); -// gFacJobDataResource.setHostDescID("testHost"); -// gFacJobDataResource.setServiceDescID("testService"); -// gFacJobDataResource.setStatus("testStatus"); -// gFacJobDataResource.setJobData("testJobData"); -// gFacJobDataResource.save(); -// -// } -// -// @Override -// public void tearDown() throws Exception { -// super.tearDown(); -// } -// -// public void testSave() throws Exception { -// GFacJobStatusResource resource = (GFacJobStatusResource)gFacJobDataResource.create(ResourceType.GFAC_JOB_STATUS); -// resource.setStatus("testStatus"); -// resource.setgFacJobDataResource(gFacJobDataResource); -// Calendar calender = Calendar.getInstance(); -// java.util.Date d = calender.getTime(); -// Timestamp timestamp = new Timestamp(d.getTime()); -// resource.setStatusUpdateTime(timestamp); -// resource.save(); -// List resources = gFacJobDataResource.get(ResourceType.GFAC_JOB_STATUS); -// assertTrue("GFac job status saved successfully", resources.size() != 0); -// } -//} http://git-wip-us.apache.org/repos/asf/airavata/blob/ec8c6202/modules/registry/experiment-catalog/src/test/java/org/apache/airavata/experiment/catalog/GatewayResourceTest.java ---------------------------------------------------------------------- diff --git a/modules/registry/experiment-catalog/src/test/java/org/apache/airavata/experiment/catalog/GatewayResourceTest.java b/modules/registry/experiment-catalog/src/test/java/org/apache/airavata/experiment/catalog/GatewayResourceTest.java deleted file mode 100644 index bd11353..0000000 --- a/modules/registry/experiment-catalog/src/test/java/org/apache/airavata/experiment/catalog/GatewayResourceTest.java +++ /dev/null @@ -1,120 +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.experiment.catalog; - -import static org.junit.Assert.*; - -import org.apache.airavata.common.utils.ServerSettings; -import org.apache.airavata.experiment.catalog.resources.*; -import org.junit.After; -import org.junit.Test; - -import java.sql.Timestamp; -import java.util.Date; - - -public class GatewayResourceTest extends AbstractResourceTest { - private GatewayResource gatewayResource; - private ProjectResource projectResource; - private UserResource userResource; - private WorkerResource workerResource; - private ExperimentResource experimentResource; - - - @Override - public void setUp() throws Exception { - super.setUp(); - Timestamp currentDate = new Timestamp(new Date().getTime()); - - gatewayResource = super.getGatewayResource(); - workerResource = super.getWorkerResource(); - userResource = super.getUserResource(); - if (gatewayResource == null) { - gatewayResource = (GatewayResource) ResourceUtils.getGateway(ServerSettings.getDefaultUserGateway()); - } - projectResource = (ProjectResource) gatewayResource.create(ResourceType.PROJECT); - projectResource.setId("testProject"); - projectResource.setName("testProject"); - projectResource.setWorker(workerResource); - projectResource.save(); - - experimentResource = (ExperimentResource) gatewayResource.create(ResourceType.EXPERIMENT); - - experimentResource.setExpID("testExpID"); - experimentResource.setExecutionUser(getWorkerResource().getUser()); - experimentResource.setProjectId(getProjectResource().getId()); - experimentResource.setCreationTime(currentDate); - experimentResource.setApplicationId("testApplication"); - experimentResource.setApplicationVersion("1.0"); - experimentResource.setDescription("Test Application"); - experimentResource.setExpName("TestExperiment"); - experimentResource.save(); - } - @Test - public void testSave() throws Exception { - gatewayResource.setDomain("owner1"); - gatewayResource.save(); - - boolean gatewayExist = ResourceUtils.isGatewayExist(ServerSettings.getDefaultUserGateway()); - assertTrue("The gateway exisits", gatewayExist); - - } - - @Test - public void testCreate() throws Exception { - assertNotNull("project resource cannot be null", projectResource); - assertNotNull("user resource cannot be null", userResource); - assertNotNull("worker resource cannot be null", workerResource); - assertNotNull("experiment resource cannot be null", experimentResource); - } - - @Test - public void testIsExists() throws Exception { - assertTrue(gatewayResource.isExists(ResourceType.GATEWAY_WORKER, ServerSettings.getDefaultUser())); - assertTrue(gatewayResource.isExists(ResourceType.EXPERIMENT, "testExpID")); - } - - @Test - public void testGet() throws Exception { - assertNotNull(gatewayResource.get(ResourceType.GATEWAY_WORKER, ServerSettings.getDefaultUser())); - assertNotNull(gatewayResource.get(ResourceType.EXPERIMENT, "testExpID")); - } - - @Test - public void testGetList() throws Exception { - assertNotNull(gatewayResource.get(ResourceType.GATEWAY_WORKER)); - assertNotNull(gatewayResource.get(ResourceType.PROJECT)); - assertNotNull(gatewayResource.get(ResourceType.EXPERIMENT)); - } - - @Test - public void testRemove() throws Exception { - - gatewayResource.remove(ResourceType.EXPERIMENT, "testExpID"); - assertFalse(gatewayResource.isExists(ResourceType.EXPERIMENT, "testExpID")); - - } - - @After - public void tearDown() throws Exception { - } -} http://git-wip-us.apache.org/repos/asf/airavata/blob/ec8c6202/modules/registry/experiment-catalog/src/test/java/org/apache/airavata/experiment/catalog/GramDataResourceTest.java ---------------------------------------------------------------------- diff --git a/modules/registry/experiment-catalog/src/test/java/org/apache/airavata/experiment/catalog/GramDataResourceTest.java b/modules/registry/experiment-catalog/src/test/java/org/apache/airavata/experiment/catalog/GramDataResourceTest.java deleted file mode 100644 index 47f8399..0000000 --- a/modules/registry/experiment-catalog/src/test/java/org/apache/airavata/experiment/catalog/GramDataResourceTest.java +++ /dev/null @@ -1,72 +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.experiment.registry.jpa; -// -//import org.apache.airavata.experiment.registry.jpa.resources.*; -// -//import java.sql.Timestamp; -//import java.util.Calendar; -// -//public class GramDataResourceTest extends AbstractResourceTest { -// private WorkflowDataResource workflowDataResource; -// -// @Override -// public void setUp() throws Exception { -// super.setUp(); -// GatewayResource gatewayResource = super.getGatewayResource(); -// WorkerResource workerResource = super.getWorkerResource(); -// -// ExperimentMetadataResource experimentResource = (ExperimentMetadataResource) gatewayResource.create(ResourceType.EXPERIMENT_METADATA); -// experimentResource.setExpID("testExpID"); -// experimentResource.setExperimentName("testExpID"); -// experimentResource.setExecutionUser(workerResource.getUser()); -// experimentResource.setProject(new ProjectResource(workerResource, gatewayResource, "testProject")); -// experimentResource.save(); -// -// workflowDataResource = (WorkflowDataResource) experimentResource.create(ResourceType.WORKFLOW_DATA); -// workflowDataResource.setWorkflowInstanceID("testWFInstance"); -// workflowDataResource.setTemplateName("testTemplate"); -// workflowDataResource.setExperimentID("testExpID"); -// Calendar calender = Calendar.getInstance(); -// java.util.Date d = calender.getTime(); -// Timestamp timestamp = new Timestamp(d.getTime()); -// workflowDataResource.setLastUpdatedTime(timestamp); -// workflowDataResource.save(); -// } -// -// public void testSave() throws Exception { -// GramDataResource gramDataResource = workflowDataResource.createGramData("testNode"); -// gramDataResource.setWorkflowDataResource(workflowDataResource); -// gramDataResource.setInvokedHost("testhost"); -// gramDataResource.setRsl("testRSL"); -// gramDataResource.save(); -// -// assertTrue("gram data saved successfully", workflowDataResource.isGramDataExists("testNode")); -// -// } -// -// @Override -// public void tearDown() throws Exception { -// super.tearDown(); -// } -// -//} http://git-wip-us.apache.org/repos/asf/airavata/blob/ec8c6202/modules/registry/experiment-catalog/src/test/java/org/apache/airavata/experiment/catalog/NodeDataResourceTest.java ---------------------------------------------------------------------- diff --git a/modules/registry/experiment-catalog/src/test/java/org/apache/airavata/experiment/catalog/NodeDataResourceTest.java b/modules/registry/experiment-catalog/src/test/java/org/apache/airavata/experiment/catalog/NodeDataResourceTest.java deleted file mode 100644 index e13c1ff..0000000 --- a/modules/registry/experiment-catalog/src/test/java/org/apache/airavata/experiment/catalog/NodeDataResourceTest.java +++ /dev/null @@ -1,72 +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.experiment.registry.jpa; -// -//import org.apache.airavata.experiment.registry.jpa.resources.*; -// -//import java.sql.Timestamp; -//import java.util.Calendar; -// -//public class NodeDataResourceTest extends AbstractResourceTest { -// private WorkflowDataResource workflowDataResource; -// -// @Override -// public void setUp() throws Exception { -// super.setUp(); -// GatewayResource gatewayResource = super.getGatewayResource(); -// WorkerResource workerResource = super.getWorkerResource(); -// -// ExperimentMetadataResource experimentResource = (ExperimentMetadataResource) gatewayResource.create(ResourceType.EXPERIMENT_METADATA); -// experimentResource.setExpID("testExpID"); -// experimentResource.setExperimentName("testExpID"); -// experimentResource.setExecutionUser(workerResource.getUser()); -// experimentResource.setProject(new ProjectResource(workerResource, gatewayResource, "testProject")); -// experimentResource.save(); -// -// workflowDataResource = (WorkflowDataResource) experimentResource.create(ResourceType.WORKFLOW_DATA); -// workflowDataResource.setWorkflowInstanceID("testWFInstance"); -// workflowDataResource.setTemplateName("testTemplate"); -// workflowDataResource.setExperimentID("testExpID"); -// Calendar calender = Calendar.getInstance(); -// java.util.Date d = calender.getTime(); -// Timestamp timestamp = new Timestamp(d.getTime()); -// workflowDataResource.setLastUpdatedTime(timestamp); -// workflowDataResource.save(); -// } -// -// public void testSave() throws Exception { -// NodeDataResource nodeDataResource = workflowDataResource.createNodeData("testNodeID"); -// nodeDataResource.setInputs("testInput"); -// -// nodeDataResource.setStatus("testStatus"); -// nodeDataResource.setExecutionIndex(0); -// nodeDataResource.save(); -// -// assertTrue("node data resource saved successfully", workflowDataResource.isNodeExists("testNodeID")); -// } -// -// @Override -// public void tearDown() throws Exception { -// super.tearDown(); -// } -// -//} http://git-wip-us.apache.org/repos/asf/airavata/blob/ec8c6202/modules/registry/experiment-catalog/src/test/java/org/apache/airavata/experiment/catalog/OrchestratorDataResourceTest.java ---------------------------------------------------------------------- diff --git a/modules/registry/experiment-catalog/src/test/java/org/apache/airavata/experiment/catalog/OrchestratorDataResourceTest.java b/modules/registry/experiment-catalog/src/test/java/org/apache/airavata/experiment/catalog/OrchestratorDataResourceTest.java deleted file mode 100644 index e545965..0000000 --- a/modules/registry/experiment-catalog/src/test/java/org/apache/airavata/experiment/catalog/OrchestratorDataResourceTest.java +++ /dev/null @@ -1,69 +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.experiment.registry.jpa; -// -//import java.util.UUID; -// -//import org.apache.airavata.common.utils.AiravataJobState; -//import org.apache.airavata.experiment.registry.jpa.resources.*; -// -//public class OrchestratorDataResourceTest extends AbstractResourceTest{ -// private OrchestratorDataResource dataResource; -// private ExperimentMetadataResource experimentResource; -// private WorkerResource workerResource; -//// private String experimentID = UUID.randomUUID().toString(); -// private String applicationName = "echo_test"; -// private GatewayResource gatewayResource; -// -// @Override -// public void setUp() throws Exception { -// super.setUp(); -// gatewayResource = super.getGatewayResource(); -// workerResource = super.getWorkerResource(); -// -// experimentResource = (ExperimentMetadataResource) gatewayResource.create(ResourceType.EXPERIMENT_METADATA); -// experimentResource.setExpID("testExpID"); -// experimentResource.setExperimentName("testExpID"); -// experimentResource.setExecutionUser(workerResource.getUser()); -// experimentResource.setProject(new ProjectResource(workerResource, gatewayResource, "testProject")); -// experimentResource.save(); -// -// dataResource = (OrchestratorDataResource) gatewayResource.create(ResourceType.ORCHESTRATOR); -// -// } -// -// public void testSave() throws Exception { -// dataResource.setExperimentID("testExpID"); -// dataResource.setStatus(AiravataJobState.State.CREATED.toString()); -// dataResource.setApplicationName(applicationName); -// dataResource.save(); -// assertNotNull("Orchestrator data resource created successfully", dataResource); -// // Get saved data -// assertNotNull("Orchestrator data resource get successfully", gatewayResource.get(ResourceType.ORCHESTRATOR, "testExpID")); -// } -// -// @Override -// public void tearDown() throws Exception { -// super.tearDown(); -// } -// -// -//}