You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@airavata.apache.org by ma...@apache.org on 2018/06/15 14:37:10 UTC

[airavata] branch group-based-auth updated (1c5e648 -> 4f334fa)

This is an automated email from the ASF dual-hosted git repository.

machristie pushed a change to branch group-based-auth
in repository https://gitbox.apache.org/repos/asf/airavata.git.


    from 1c5e648  AIRAVATA-2827 Upgrade OpenJPA to 2.4.3
     new 5b2aa80  AIRAVATA-2827 OpenJPA 2.4.3 upgrade: convert BIT to TINYINT(1)
     new 46de1e4  Updating devjobs monitoring email password
     new 4f334fa  AIRAVATA-2827 Populate JobStatusPK from Job's PK

The 3 revisions listed above as "new" are entirely new to this
repository and will be described in separate emails.  The revisions
listed as "add" were already present in the repository and have only
been added to this reference.


Summary of changes:
 .../scigap/develop/group_vars/all/vault.yml        | 66 +++++++++++-----------
 .../group-based-auth/group_vars/all/vault.yml      | 66 +++++++++++-----------
 .../repositories/expcatalog/JobRepository.java     | 13 +++--
 .../repositories/expcatalog/TaskRepository.java    |  7 ++-
 .../src/main/resources/appcatalog-mysql.sql        |  3 +-
 .../src/main/resources/expcatalog-mysql.sql        |  4 +-
 .../expcatalog/ProcessRepositoryTest.java          | 20 +++++--
 .../next/DeltaScripts/appCatalog_schema_delta.sql  | 11 +++-
 .../experimentCatalog_schema_delta.sql             |  7 ++-
 9 files changed, 117 insertions(+), 80 deletions(-)

-- 
To stop receiving notification emails like this one, please contact
machristie@apache.org.

[airavata] 03/03: AIRAVATA-2827 Populate JobStatusPK from Job's PK

Posted by ma...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

machristie pushed a commit to branch group-based-auth
in repository https://gitbox.apache.org/repos/asf/airavata.git

commit 4f334fa864bab290f21938df5b36d413ed06eed6
Author: Marcus Christie <ma...@apache.org>
AuthorDate: Fri Jun 15 10:35:23 2018 -0400

    AIRAVATA-2827 Populate JobStatusPK from Job's PK
---
 .../core/repositories/expcatalog/JobRepository.java  | 13 +++++++++----
 .../core/repositories/expcatalog/TaskRepository.java |  7 ++++++-
 .../expcatalog/ProcessRepositoryTest.java            | 20 ++++++++++++++++----
 3 files changed, 31 insertions(+), 9 deletions(-)

diff --git a/modules/registry-refactoring/src/main/java/org/apache/airavata/registry/core/repositories/expcatalog/JobRepository.java b/modules/registry-refactoring/src/main/java/org/apache/airavata/registry/core/repositories/expcatalog/JobRepository.java
index 25af655..3744913 100644
--- a/modules/registry-refactoring/src/main/java/org/apache/airavata/registry/core/repositories/expcatalog/JobRepository.java
+++ b/modules/registry-refactoring/src/main/java/org/apache/airavata/registry/core/repositories/expcatalog/JobRepository.java
@@ -69,11 +69,18 @@ public class JobRepository extends ExpCatAbstractRepository<JobModel, JobEntity,
         }
 
 
-        String jobId = jobPK.getJobId();
-        String taskId = jobPK.getTaskId();
         Mapper mapper = ObjectMapperSingleton.getInstance();
         JobEntity jobEntity = mapper.map(jobModel, JobEntity.class);
 
+        populateParentIds(jobEntity);
+
+        return execute(entityManager -> entityManager.merge(jobEntity));
+    }
+
+    protected void populateParentIds(JobEntity jobEntity) {
+
+        String jobId = jobEntity.getJobId();
+        String taskId = jobEntity.getTaskId();
         if (jobEntity.getJobStatuses() != null) {
             logger.debug("Populating the Primary Key of JobStatus objects for the Job");
             jobEntity.getJobStatuses().forEach(jobStatusEntity -> {
@@ -81,8 +88,6 @@ public class JobRepository extends ExpCatAbstractRepository<JobModel, JobEntity,
                 jobStatusEntity.setTaskId(taskId);
             });
         }
-
-        return execute(entityManager -> entityManager.merge(jobEntity));
     }
 
     public String addJob(JobModel job, String processId) throws RegistryException {
diff --git a/modules/registry-refactoring/src/main/java/org/apache/airavata/registry/core/repositories/expcatalog/TaskRepository.java b/modules/registry-refactoring/src/main/java/org/apache/airavata/registry/core/repositories/expcatalog/TaskRepository.java
index 7c2404d..268e7c8 100644
--- a/modules/registry-refactoring/src/main/java/org/apache/airavata/registry/core/repositories/expcatalog/TaskRepository.java
+++ b/modules/registry-refactoring/src/main/java/org/apache/airavata/registry/core/repositories/expcatalog/TaskRepository.java
@@ -40,6 +40,8 @@ import java.util.Map;
 public class TaskRepository extends ExpCatAbstractRepository<TaskModel, TaskEntity, String> {
     private final static Logger logger = LoggerFactory.getLogger(TaskRepository.class);
 
+    private final JobRepository jobRepository = new JobRepository();
+
     public TaskRepository() { super(TaskModel.class, TaskEntity.class); }
 
     protected String saveTaskModelData(TaskModel taskModel) throws RegistryException {
@@ -95,7 +97,10 @@ public class TaskRepository extends ExpCatAbstractRepository<TaskModel, TaskEnti
 
         if (taskEntity.getJobs() != null) {
             logger.debug("Populating the Job objects' Task ID for the Task");
-            taskEntity.getJobs().forEach(jobEntity -> jobEntity.setTaskId(taskId));
+            taskEntity.getJobs().forEach(jobEntity -> {
+                jobEntity.setTaskId(taskId);
+                jobRepository.populateParentIds(jobEntity);
+            });
         }
     }
 
diff --git a/modules/registry-refactoring/src/test/java/org/apache/airavata/registry/core/repositories/expcatalog/ProcessRepositoryTest.java b/modules/registry-refactoring/src/test/java/org/apache/airavata/registry/core/repositories/expcatalog/ProcessRepositoryTest.java
index b454738..dada4d0 100644
--- a/modules/registry-refactoring/src/test/java/org/apache/airavata/registry/core/repositories/expcatalog/ProcessRepositoryTest.java
+++ b/modules/registry-refactoring/src/test/java/org/apache/airavata/registry/core/repositories/expcatalog/ProcessRepositoryTest.java
@@ -22,12 +22,10 @@ package org.apache.airavata.registry.core.repositories.expcatalog;
 
 import org.apache.airavata.model.experiment.ExperimentModel;
 import org.apache.airavata.model.experiment.ExperimentType;
+import org.apache.airavata.model.job.JobModel;
 import org.apache.airavata.model.process.ProcessModel;
 import org.apache.airavata.model.scheduling.ComputationalResourceSchedulingModel;
-import org.apache.airavata.model.status.ProcessState;
-import org.apache.airavata.model.status.ProcessStatus;
-import org.apache.airavata.model.status.TaskState;
-import org.apache.airavata.model.status.TaskStatus;
+import org.apache.airavata.model.status.*;
 import org.apache.airavata.model.task.TaskModel;
 import org.apache.airavata.model.task.TaskTypes;
 import org.apache.airavata.model.workspace.Gateway;
@@ -118,6 +116,19 @@ public class ProcessRepositoryTest {
 
         processModel.setProcessDetail("detail");
         processModel.setUseUserCRPref(true);
+
+        TaskModel jobSubmissionTask = new TaskModel();
+        jobSubmissionTask.setTaskType(TaskTypes.JOB_SUBMISSION);
+        jobSubmissionTask.setTaskId("job-task-id");
+        JobModel job = new JobModel();
+        job.setProcessId(processId);
+        job.setJobId("job-id");
+        job.setJobDescription("job-description");
+        JobStatus jobStatus = new JobStatus(JobState.SUBMITTED);
+        jobStatus.setStatusId("submitted-job-status-id");
+        job.addToJobStatuses(jobStatus);
+        jobSubmissionTask.addToJobs(job);
+        processModel.addToTasks(jobSubmissionTask);
         processRepository.updateProcess(processModel, processId);
 
         ProcessModel retrievedProcess = processRepository.getProcess(processId);
@@ -126,6 +137,7 @@ public class ProcessRepositoryTest {
         assertTrue(retrievedProcess.isUseUserCRPref());
         assertEquals(1, retrievedProcess.getProcessStatusesSize());
         assertEquals(ProcessState.CREATED, retrievedProcess.getProcessStatuses().get(0).getState());
+        assertEquals(2, retrievedProcess.getTasksSize());
 
         ComputationalResourceSchedulingModel computationalResourceSchedulingModel = new ComputationalResourceSchedulingModel();
         assertEquals(processId, processRepository.addProcessResourceSchedule(computationalResourceSchedulingModel, processId));

-- 
To stop receiving notification emails like this one, please contact
machristie@apache.org.

[airavata] 02/03: Updating devjobs monitoring email password

Posted by ma...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

machristie pushed a commit to branch group-based-auth
in repository https://gitbox.apache.org/repos/asf/airavata.git

commit 46de1e4096d0fd8cb8ae58e608c65a595b4386d3
Author: Marcus Christie <ma...@apache.org>
AuthorDate: Fri Jun 15 10:04:34 2018 -0400

    Updating devjobs monitoring email password
---
 .../scigap/develop/group_vars/all/vault.yml        | 66 +++++++++++-----------
 .../group-based-auth/group_vars/all/vault.yml      | 66 +++++++++++-----------
 2 files changed, 66 insertions(+), 66 deletions(-)

diff --git a/dev-tools/ansible/inventories/scigap/develop/group_vars/all/vault.yml b/dev-tools/ansible/inventories/scigap/develop/group_vars/all/vault.yml
index b07d280..11b3eff 100644
--- a/dev-tools/ansible/inventories/scigap/develop/group_vars/all/vault.yml
+++ b/dev-tools/ansible/inventories/scigap/develop/group_vars/all/vault.yml
@@ -1,34 +1,34 @@
 $ANSIBLE_VAULT;1.1;AES256
-61393763303962643965393638306661363734623732313164343036323966663439643062326165
-3562623062353030393930643239326435663666666465640a636231356531666338633162643237
-64616265353630376434666638633334326630346361663161326639393166663261653137613332
-3136353739666266320a366434636630626136393433613563643131626531313339643430626532
-64343066643036366231373534343939616437376537653436313564393731376265663065343038
-31643536613835643733623638366236316235366365306535366431353339393666373234666234
-30643565353733663362656439366636383861663134623834663635323335303530663966303833
-38646263316236653936666438333365356136373632653537323539316561323332666637613064
-66623565613063386262633236636463343765376631616538653539366638623563626537333365
-63363666383438343736623532343664386162356161613939366537636536366363663061633139
-64343665303931366531613566303062623336393232333263366262363832336230356137376266
-64353536646431663562636663353437343536613031626338303837316337346636643836613564
-63306532656437393531343039666333396161613337636637383535643837356233316536313338
-36373736366631313039643436306139643934613862313462353537663932343365376139346134
-62306637653166383066656564333265333433373261346638333933616237336466653131343164
-34363834303235303565633039636463363633363366663139646336323732346264336536366665
-32326261623964323639333166633063353636656365373337633238393739386234313738393030
-32366463393564393364316231643638653833643738373965353363336265336534396166633936
-64323234333033613832646139616163386434646237636534313933396639626362346636653664
-62326361336164656430626635383738653464323166323139666162316265316435613035323431
-62643366313961623833376365626436623331363364346462326264376361663539353066343432
-39343337343265616263626462376566386433656465623135366663623162353866613137343331
-35663366363933326565656430613663626332306163346334333534373139313930633131666231
-36663166336664636537613964626330313463363838613130323862663438636466356134363334
-65653564306331623938646438613965336361643165373130333237656138393635363962633539
-31313466656464356437386339333065373661356332356264336238333736653163326539373963
-66303630333431626331353166333633656636616366396661366333343532383361303031343036
-36316239363939666638396535306232366336633164356338353963646361626131366233616465
-35613661666538303766633666383136373762316633623639383231383064616263633565313066
-65336636643435396536313537343434303066653135303831393565313664386137376663666661
-62393761303664343266613262376435323864396631376161346461636537636535353435303064
-37336636376630376662323137316263643839646663313839663731336364653336343737376261
-6331
+62633563633539333964376337353936303532313039313636636134333831303139366361396465
+6639643834623637663162613062386466633364636337340a646365613739306633363233346539
+63643361303835623035316238646239613964663735333631326262323735376365313534346335
+6665346235316439620a633265316236336330316138666262396338383335343863303939333531
+31393339313831316635616565313038613061393865646530323936303834623230663030626336
+38313930613461623661616533333336393666343266656639383934303362643036333465363338
+31336336316434336537333537366665383439353630663764306265363934626564626462363863
+66313035316636656662333533353264356665376666313631386534383865383734383831303833
+35663962646462643461383034333433343064326139646662643931363063383166613739653333
+39333464343063646638373163366531313830306266633031336432323836356338636530663131
+35623765636462393535643363613635623666643565386535616663373463343039333035623337
+34303061326336656338613839343661303937323366336632373866343266373861353537306562
+64393362623932383464326363363461633734393662643239643138663733643134636332643539
+38396338333934373831343931653266306231656663363139626333653534356130613535643434
+30633963373536626635393635333637316637393838343935333162313162666637303961323066
+37346261643330303664343536633861396139616335386665666639643462313164396365613837
+61313264333162376533333834353231313039343233353332643032613431323633323261373330
+31646532383532666436313764626632366235333665313737326561353463363666653131623564
+36316430383730643135343331343237383239356131643735623237633932636362633361323261
+33636432306532376230636333343838326234323734653765333436323930373635373234313063
+30653661616337363235333837653638383165306538323665386136326534386532346231613765
+30633931343831666464396363646630373866373865373036323536363533633966656635303865
+61383738623638373962656335343464666533393837336139643437323930646163333030336136
+33653963616530646162656439636563373238396439383965646335633064613832653838366362
+64636265343333346166363064616264303734343831326633363932366535643732646435353336
+39323435303638373533633839333262613663646366613638653163643631346230626235636463
+62653763373436353932363939326537656636636665396238313161303438633637363834316164
+34643634373530346533393663303934346561656138636465336434366464393530303864313536
+35653365363037373732386433326332363437353964323630383061663138623736356338366238
+63633465633462393735366538396162356464653538636635636433363531326536333139303062
+66376335356139616565616536336632303338656631396138326533626130633931626163303365
+34653864623765313438653731613165643639316339643265353639616433653731373537316533
+3964
diff --git a/dev-tools/ansible/inventories/scigap/group-based-auth/group_vars/all/vault.yml b/dev-tools/ansible/inventories/scigap/group-based-auth/group_vars/all/vault.yml
index b07d280..aedcb63 100644
--- a/dev-tools/ansible/inventories/scigap/group-based-auth/group_vars/all/vault.yml
+++ b/dev-tools/ansible/inventories/scigap/group-based-auth/group_vars/all/vault.yml
@@ -1,34 +1,34 @@
 $ANSIBLE_VAULT;1.1;AES256
-61393763303962643965393638306661363734623732313164343036323966663439643062326165
-3562623062353030393930643239326435663666666465640a636231356531666338633162643237
-64616265353630376434666638633334326630346361663161326639393166663261653137613332
-3136353739666266320a366434636630626136393433613563643131626531313339643430626532
-64343066643036366231373534343939616437376537653436313564393731376265663065343038
-31643536613835643733623638366236316235366365306535366431353339393666373234666234
-30643565353733663362656439366636383861663134623834663635323335303530663966303833
-38646263316236653936666438333365356136373632653537323539316561323332666637613064
-66623565613063386262633236636463343765376631616538653539366638623563626537333365
-63363666383438343736623532343664386162356161613939366537636536366363663061633139
-64343665303931366531613566303062623336393232333263366262363832336230356137376266
-64353536646431663562636663353437343536613031626338303837316337346636643836613564
-63306532656437393531343039666333396161613337636637383535643837356233316536313338
-36373736366631313039643436306139643934613862313462353537663932343365376139346134
-62306637653166383066656564333265333433373261346638333933616237336466653131343164
-34363834303235303565633039636463363633363366663139646336323732346264336536366665
-32326261623964323639333166633063353636656365373337633238393739386234313738393030
-32366463393564393364316231643638653833643738373965353363336265336534396166633936
-64323234333033613832646139616163386434646237636534313933396639626362346636653664
-62326361336164656430626635383738653464323166323139666162316265316435613035323431
-62643366313961623833376365626436623331363364346462326264376361663539353066343432
-39343337343265616263626462376566386433656465623135366663623162353866613137343331
-35663366363933326565656430613663626332306163346334333534373139313930633131666231
-36663166336664636537613964626330313463363838613130323862663438636466356134363334
-65653564306331623938646438613965336361643165373130333237656138393635363962633539
-31313466656464356437386339333065373661356332356264336238333736653163326539373963
-66303630333431626331353166333633656636616366396661366333343532383361303031343036
-36316239363939666638396535306232366336633164356338353963646361626131366233616465
-35613661666538303766633666383136373762316633623639383231383064616263633565313066
-65336636643435396536313537343434303066653135303831393565313664386137376663666661
-62393761303664343266613262376435323864396631376161346461636537636535353435303064
-37336636376630376662323137316263643839646663313839663731336364653336343737376261
-6331
+33343633316537356163356331343736613963386332653834653835396533323165633363393936
+3432373863643738333137343333313065383037326666650a323361653661653962336238333066
+64626335306537326534313430623036623566373961373435643432643264373765663664373130
+3933303831623236310a373762396536323230303833643264323864393132383036623139646361
+66633837623231656437376138343263366436333661326134616134333436366634656135373734
+30653961626133396430656332623261643465613165306234636334373364313630666239353735
+39656230346230373163633137663031363334663966313661366561376232666366366136646161
+33313930646237656163663230313136323037356433383635323639663435336163323933643863
+31313231636364383135363566323234613165356233383234326532323266633030303565333832
+33646164373864393039373838326232326131633233323264623335666635363539306566353363
+35383237626561663739373062653332653039306366373164353531373134373665653531613735
+62383165336566646333323962333734653330356666323261303731383430383434636337306635
+65626432333563613864313562336264393062663464616337333636623538353533373261316463
+39396638393766366566323237623662366436346537396464616665303235386238656361313261
+66616230313438646631323632343331613762393538666130363032383538336134616461326665
+36653934653864643165363136613164666466353639356433396361366430316564393766383866
+64356437306230623631313036313162336664616263343034636435393935636236653162363032
+61363332663565353265306264626330373434316131366364623134313434663132613463393137
+37363732313137373930653933643535623832396230626238373534386239613566316462393330
+65353233376661646661616663376461313531623265366161346538353337626636303461636136
+63656161656538666435336561386239316337653533336433356639626235303337373438366232
+32666134326662616435396230323864373763623134663134333630663136356338376530306530
+37336533376332366631356237383138336130663366333132643835633966313939636531323632
+37656636613365336131626330633932326464343465306165636530663863623930373662373064
+39333564653166326564393966613733383039336336653130343766363461636138306561396339
+66363263343464373938653266613762666334633731343836333239316636636265623334616537
+62336633393361336539356538346138643338643937623864366635353861376639666637316235
+38653133373633323235346433663331313034663166366538353133623433656134323137626237
+35643638323835333037393064393631333331323031643336633365363833656332646636383339
+31633066313130336434623663316433613436373564323065623062373037316263653063313836
+39323635393562303339633831393562633932393235306232326462306235636163633563303333
+63613834333064383136616234313364376538396338363139613031626564393635373733373034
+3362

-- 
To stop receiving notification emails like this one, please contact
machristie@apache.org.

[airavata] 01/03: AIRAVATA-2827 OpenJPA 2.4.3 upgrade: convert BIT to TINYINT(1)

Posted by ma...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

machristie pushed a commit to branch group-based-auth
in repository https://gitbox.apache.org/repos/asf/airavata.git

commit 5b2aa800a1e9e47a713dc07e89eff7130291a118
Author: Marcus Christie <ma...@apache.org>
AuthorDate: Fri Jun 15 09:31:48 2018 -0400

    AIRAVATA-2827 OpenJPA 2.4.3 upgrade: convert BIT to TINYINT(1)
---
 .../src/main/resources/appcatalog-mysql.sql                   |  3 ++-
 .../src/main/resources/expcatalog-mysql.sql                   |  4 ++--
 .../next/DeltaScripts/appCatalog_schema_delta.sql             | 11 ++++++++++-
 .../next/DeltaScripts/experimentCatalog_schema_delta.sql      |  7 ++++++-
 4 files changed, 20 insertions(+), 5 deletions(-)

diff --git a/modules/registry-refactoring/src/main/resources/appcatalog-mysql.sql b/modules/registry-refactoring/src/main/resources/appcatalog-mysql.sql
index 9663dee..39a0069 100644
--- a/modules/registry-refactoring/src/main/resources/appcatalog-mysql.sql
+++ b/modules/registry-refactoring/src/main/resources/appcatalog-mysql.sql
@@ -31,7 +31,7 @@ CREATE TABLE COMPUTE_RESOURCE
           DEFAULT_CPU_COUNT INTEGER,
           DEFAULT_WALLTIME INTEGER,
           ENABLED SMALLINT,
-          GATEWAY_USAGE_REPORTING SMALLINT,
+          GATEWAY_USAGE_REPORTING TINYINT(1),
           GATEWAY_USAGE_MODULE_LOAD_CMD VARCHAR(500),
           GATEWAY_USAGE_EXECUTABLE VARCHAR(255),
           PRIMARY KEY (RESOURCE_ID)
@@ -277,6 +277,7 @@ CREATE TABLE APPLICATION_INTERFACE
          APPLICATION_DESCRIPTION VARCHAR(500),
          GATEWAY_ID VARCHAR(255),
          ARCHIVE_WORKING_DIRECTORY SMALLINT,
+         HAS_OPTIONAL_FILE_INPUTS TINYINT(1),
 	       CREATION_TIME TIMESTAMP DEFAULT NOW(),
          UPDATE_TIME TIMESTAMP DEFAULT '0000-00-00 00:00:00',
          PRIMARY KEY(INTERFACE_ID)
diff --git a/modules/registry-refactoring/src/main/resources/expcatalog-mysql.sql b/modules/registry-refactoring/src/main/resources/expcatalog-mysql.sql
index 29952e5..1dbfe33 100644
--- a/modules/registry-refactoring/src/main/resources/expcatalog-mysql.sql
+++ b/modules/registry-refactoring/src/main/resources/expcatalog-mysql.sql
@@ -237,7 +237,7 @@ CREATE TABLE PROCESS (
         EXPERIMENT_DATA_DIR VARCHAR (512),
         USERNAME VARCHAR (255),
         GROUP_RESOURCE_PROFILE_ID VARCHAR (255) DEFAULT NULL,
-        USE_USER_CR_PREF BIT(1),
+        USE_USER_CR_PREF TINYINT(1),
         PRIMARY KEY (PROCESS_ID),
         FOREIGN KEY (EXPERIMENT_ID) REFERENCES EXPERIMENT(EXPERIMENT_ID) ON DELETE CASCADE
 );
@@ -383,7 +383,7 @@ CREATE TABLE QUEUE_STATUS(
         HOST_NAME VARCHAR(255),
         QUEUE_NAME VARCHAR(255),
         CREATED_TIME BIGINT(20),
-        QUEUE_UP     BIT(1),
+        QUEUE_UP     TINYINT(1),
         RUNNING_JOBS INT(11),
         QUEUED_JOBS INT(11),
         PRIMARY KEY (HOST_NAME, QUEUE_NAME, CREATED_TIME)
diff --git a/modules/registry/release-migration-scripts/next/DeltaScripts/appCatalog_schema_delta.sql b/modules/registry/release-migration-scripts/next/DeltaScripts/appCatalog_schema_delta.sql
index def5dcf..272ed9b 100644
--- a/modules/registry/release-migration-scripts/next/DeltaScripts/appCatalog_schema_delta.sql
+++ b/modules/registry/release-migration-scripts/next/DeltaScripts/appCatalog_schema_delta.sql
@@ -28,4 +28,13 @@ alter table COMPUTE_RESOURCE modify column CPUS_PER_NODE int default 0 null;
 alter table COMPUTE_RESOURCE modify column DEFAULT_NODE_COUNT int default 0 null;
 alter table COMPUTE_RESOURCE modify column DEFAULT_CPU_COUNT int default 0 null;
 alter table COMPUTE_RESOURCE modify column DEFAULT_WALLTIME int default 0 null;
-alter table COMPUTE_RESOURCE modify column UPDATE_TIME timestamp default '0000-00-00 00:00:00' null;
\ No newline at end of file
+alter table COMPUTE_RESOURCE modify column UPDATE_TIME timestamp default '0000-00-00 00:00:00' null;
+
+-- AIRAVATA-2827: OpenJPA 2.4.3 upgrade, convert BIT -> TINYINT(1)
+alter table APPLICATION_OUTPUT modify column OUTPUT_STREAMING tinyint(1);
+alter table APPLICATION_INTERFACE modify column ARCHIVE_WORKING_DIRECTORY tinyint(1);
+alter table APPLICATION_INTERFACE modify column HAS_OPTIONAL_FILE_INPUTS tinyint(1);
+alter table APPLICATION_DEPLOYMENT modify column EDITABLE_BY_USER tinyint(1);
+alter table BATCH_QUEUE modify column IS_DEFAULT_QUEUE tinyint(1);
+alter table COMPUTE_RESOURCE modify column GATEWAY_USAGE_REPORTING tinyint(1);
+alter table USER_COMPUTE_RESOURCE_PREFERENCE modify column VALIDATED tinyint(1) default 0;
\ No newline at end of file
diff --git a/modules/registry/release-migration-scripts/next/DeltaScripts/experimentCatalog_schema_delta.sql b/modules/registry/release-migration-scripts/next/DeltaScripts/experimentCatalog_schema_delta.sql
index f70fdd2..9b19987 100644
--- a/modules/registry/release-migration-scripts/next/DeltaScripts/experimentCatalog_schema_delta.sql
+++ b/modules/registry/release-migration-scripts/next/DeltaScripts/experimentCatalog_schema_delta.sql
@@ -22,4 +22,9 @@
 alter table EXPERIMENT_INPUT modify METADATA VARCHAR(4096);
 
 -- AIRAVATA-2820
-alter table TASK drop column TASK_INTERNAL_STORE;
\ No newline at end of file
+alter table TASK drop column TASK_INTERNAL_STORE;
+
+-- AIRAVATA-2827: OpenJPA 2.4.3 upgrade, convert BIT -> TINYINT(1)
+alter table PROCESS modify column USE_USER_CR_PREF tinyint(1);
+alter table QUEUE_STATUS modify column QUEUE_UP tinyint(1);
+alter table USER_CONFIGURATION_DATA modify column IS_USE_USER_CR_PREF tinyint(1);

-- 
To stop receiving notification emails like this one, please contact
machristie@apache.org.