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 11B8017ED3 for ; Mon, 6 Oct 2014 19:54:57 +0000 (UTC) Received: (qmail 16352 invoked by uid 500); 6 Oct 2014 19:54:50 -0000 Delivered-To: apmail-airavata-commits-archive@airavata.apache.org Received: (qmail 16173 invoked by uid 500); 6 Oct 2014 19:54:50 -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 15885 invoked by uid 99); 6 Oct 2014 19:54:50 -0000 Received: from tyr.zones.apache.org (HELO tyr.zones.apache.org) (140.211.11.114) by apache.org (qpsmtpd/0.29) with ESMTP; Mon, 06 Oct 2014 19:54:50 +0000 Received: by tyr.zones.apache.org (Postfix, from userid 65534) id 189C18B3330; Mon, 6 Oct 2014 19:54:50 +0000 (UTC) Content-Type: text/plain; charset="us-ascii" MIME-Version: 1.0 Content-Transfer-Encoding: 7bit From: chathuri@apache.org To: commits@airavata.apache.org Date: Mon, 06 Oct 2014 19:54:54 -0000 Message-Id: In-Reply-To: References: X-Mailer: ASF-Git Admin Mailer Subject: [06/23] git commit: updating branch to use new status change events updating branch to use new status change events Project: http://git-wip-us.apache.org/repos/asf/airavata/repo Commit: http://git-wip-us.apache.org/repos/asf/airavata/commit/785394d3 Tree: http://git-wip-us.apache.org/repos/asf/airavata/tree/785394d3 Diff: http://git-wip-us.apache.org/repos/asf/airavata/diff/785394d3 Branch: refs/heads/master Commit: 785394d34f71452f3ecfe91be8057117bc35ad85 Parents: 1fe3d1d Author: Chathuri Wimalasena Authored: Mon Aug 11 13:38:55 2014 -0400 Committer: Chathuri Wimalasena Committed: Mon Aug 11 13:38:55 2014 -0400 ---------------------------------------------------------------------- .../AiravataExperimentStatusUpdator.java | 13 +- .../listener/ExperimentStatusChangedEvent.java | 128 +++++----- .../lib/airavata/messagingEvents_types.cpp | 197 +-------------- .../lib/airavata/messagingEvents_types.h | 123 +-------- .../Airavata/Model/Messaging/Event/Types.php | 251 ------------------- .../messaging/event/JobStatusChangeEvent.java | 105 +------- .../messagingEvents.thrift | 24 +- .../main/resources/airavata-server.properties | 2 + .../core/monitor/AiravataJobStatusUpdator.java | 13 +- .../core/monitor/AiravataTaskStatusUpdator.java | 14 +- .../AiravataWorkflowNodeStatusUpdator.java | 14 +- .../gfac/core/monitor/ExperimentIdentity.java | 72 +++--- .../airavata/gfac/core/monitor/JobIdentity.java | 78 +++--- .../gfac/core/monitor/TaskIdentity.java | 76 +++--- .../gfac/core/monitor/WorkflowNodeIdentity.java | 74 +++--- .../monitor/state/JobStatusChangeRequest.java | 162 ++++++------ .../monitor/state/JobStatusChangedEvent.java | 162 ++++++------ .../state/TaskOutputDataChangedEvent.java | 128 +++++----- .../monitor/state/TaskStatusChangeRequest.java | 124 ++++----- .../monitor/state/TaskStatusChangedEvent.java | 124 ++++----- .../state/WorkflowNodeStatusChangedEvent.java | 128 +++++----- .../airavata/messaging/core/Publisher.java | 8 +- .../core/impl/AiravataRabbitMQPublisher.java | 46 ++++ 23 files changed, 731 insertions(+), 1335 deletions(-) ---------------------------------------------------------------------- http://git-wip-us.apache.org/repos/asf/airavata/blob/785394d3/airavata-api/airavata-api-server/src/main/java/org/apache/airavata/api/server/listener/AiravataExperimentStatusUpdator.java ---------------------------------------------------------------------- diff --git a/airavata-api/airavata-api-server/src/main/java/org/apache/airavata/api/server/listener/AiravataExperimentStatusUpdator.java b/airavata-api/airavata-api-server/src/main/java/org/apache/airavata/api/server/listener/AiravataExperimentStatusUpdator.java index ae3e67d..903e630 100644 --- a/airavata-api/airavata-api-server/src/main/java/org/apache/airavata/api/server/listener/AiravataExperimentStatusUpdator.java +++ b/airavata-api/airavata-api-server/src/main/java/org/apache/airavata/api/server/listener/AiravataExperimentStatusUpdator.java @@ -25,7 +25,8 @@ import java.util.Calendar; import org.apache.airavata.api.server.util.DataModelUtils; import org.apache.airavata.common.utils.MonitorPublisher; import org.apache.airavata.common.utils.listener.AbstractActivityListener; -import org.apache.airavata.gfac.core.monitor.state.WorkflowNodeStatusChangedEvent; +import org.apache.airavata.model.messaging.event.ExperimentStatusChangeEvent; +import org.apache.airavata.model.messaging.event.WorkflowNodeStatusChangeEvent; import org.apache.airavata.model.util.ExecutionType; import org.apache.airavata.model.workspace.experiment.Experiment; import org.apache.airavata.model.workspace.experiment.ExperimentState; @@ -51,7 +52,7 @@ public class AiravataExperimentStatusUpdator implements AbstractActivityListener } @Subscribe - public void setupExperimentStatus(WorkflowNodeStatusChangedEvent nodeStatus) { + public void setupExperimentStatus(WorkflowNodeStatusChangeEvent nodeStatus) { try { boolean updateExperimentStatus=true; ExperimentState state = ExperimentState.UNKNOWN; @@ -78,12 +79,12 @@ public class AiravataExperimentStatusUpdator implements AbstractActivityListener break; } if (!updateExperimentStatus){ - ExecutionType executionType = DataModelUtils.getExecutionType((Experiment) airavataRegistry.get(RegistryModelType.EXPERIMENT, nodeStatus.getIdentity().getExperimentID())); + ExecutionType executionType = DataModelUtils.getExecutionType((Experiment) airavataRegistry.get(RegistryModelType.EXPERIMENT, nodeStatus.getWorkflowNodeIdentity().getExperimentID())); updateExperimentStatus=(executionType==ExecutionType.SINGLE_APP); } - updateExperimentStatus(nodeStatus.getIdentity().getExperimentID(), state); - logger.debug("Publishing experiment status for "+nodeStatus.getIdentity().getExperimentID()+":"+state.toString()); - monitorPublisher.publish(new ExperimentStatusChangedEvent(nodeStatus.getIdentity(), state)); + updateExperimentStatus(nodeStatus.getWorkflowNodeIdentity().getExperimentId(), state); + logger.debug("Publishing experiment status for "+nodeStatus.getWorkflowNodeIdentity().getExperimentId()+":"+state.toString()); + monitorPublisher.publish(new ExperimentStatusChangeEvent(state, nodeStatus.getWorkflowNodeIdentity().getExperimentId())); } catch (Exception e) { logger.error("Error persisting data" + e.getLocalizedMessage(), e); } http://git-wip-us.apache.org/repos/asf/airavata/blob/785394d3/airavata-api/airavata-api-server/src/main/java/org/apache/airavata/api/server/listener/ExperimentStatusChangedEvent.java ---------------------------------------------------------------------- diff --git a/airavata-api/airavata-api-server/src/main/java/org/apache/airavata/api/server/listener/ExperimentStatusChangedEvent.java b/airavata-api/airavata-api-server/src/main/java/org/apache/airavata/api/server/listener/ExperimentStatusChangedEvent.java index d4229e2..722f150 100644 --- a/airavata-api/airavata-api-server/src/main/java/org/apache/airavata/api/server/listener/ExperimentStatusChangedEvent.java +++ b/airavata-api/airavata-api-server/src/main/java/org/apache/airavata/api/server/listener/ExperimentStatusChangedEvent.java @@ -1,64 +1,64 @@ -/* - * - * 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.api.server.listener; - -import org.apache.airavata.common.utils.listener.AbstractStateChangeRequest; -import org.apache.airavata.gfac.core.monitor.ExperimentIdentity; -import org.apache.airavata.model.workspace.experiment.ExperimentState; - -/** - * This is the primary job state object used in - * through out the monitor module. This use airavata-data-model JobState enum - * Ideally after processing each event or monitoring message from remote system - * Each monitoring implementation has to return this object with a state and - * the monitoring ID - */ -public class ExperimentStatusChangedEvent extends AbstractStateChangeRequest { - private ExperimentState state; - private ExperimentIdentity identity; - - // this constructor can be used in Qstat monitor to handle errors - public ExperimentStatusChangedEvent() { - } - - public ExperimentStatusChangedEvent(ExperimentIdentity experimentIdentity, ExperimentState state) { - this.state = state; - setIdentity(experimentIdentity); - } - - public ExperimentState getState() { - return state; - } - - public void setState(ExperimentState state) { - this.state = state; - } - - public ExperimentIdentity getIdentity() { - return identity; - } - - public void setIdentity(ExperimentIdentity identity) { - this.identity = identity; - } - - -} +///* +// * +// * 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.api.server.listener; +// +//import org.apache.airavata.common.utils.listener.AbstractStateChangeRequest; +//import org.apache.airavata.gfac.core.monitor.ExperimentIdentity; +//import org.apache.airavata.model.workspace.experiment.ExperimentState; +// +///** +// * This is the primary job state object used in +// * through out the monitor module. This use airavata-data-model JobState enum +// * Ideally after processing each event or monitoring message from remote system +// * Each monitoring implementation has to return this object with a state and +// * the monitoring ID +// */ +//public class ExperimentStatusChangedEvent extends AbstractStateChangeRequest { +// private ExperimentState state; +// private ExperimentIdentity identity; +// +// // this constructor can be used in Qstat monitor to handle errors +// public ExperimentStatusChangedEvent() { +// } +// +// public ExperimentStatusChangedEvent(ExperimentIdentity experimentIdentity, ExperimentState state) { +// this.state = state; +// setIdentity(experimentIdentity); +// } +// +// public ExperimentState getState() { +// return state; +// } +// +// public void setState(ExperimentState state) { +// this.state = state; +// } +// +// public ExperimentIdentity getIdentity() { +// return identity; +// } +// +// public void setIdentity(ExperimentIdentity identity) { +// this.identity = identity; +// } +// +// +//} http://git-wip-us.apache.org/repos/asf/airavata/blob/785394d3/airavata-api/airavata-client-sdks/airavata-cpp-sdk/src/main/resources/lib/airavata/messagingEvents_types.cpp ---------------------------------------------------------------------- diff --git a/airavata-api/airavata-client-sdks/airavata-cpp-sdk/src/main/resources/lib/airavata/messagingEvents_types.cpp b/airavata-api/airavata-client-sdks/airavata-cpp-sdk/src/main/resources/lib/airavata/messagingEvents_types.cpp index 0c14c72..956def7 100644 --- a/airavata-api/airavata-client-sdks/airavata-cpp-sdk/src/main/resources/lib/airavata/messagingEvents_types.cpp +++ b/airavata-api/airavata-client-sdks/airavata-cpp-sdk/src/main/resources/lib/airavata/messagingEvents_types.cpp @@ -561,179 +561,8 @@ void swap(JobIdentity &a, JobIdentity &b) { swap(a.experimentId, b.experimentId); } -const char* JobMonitor::ascii_fingerprint = "D0036787E2FC651CBEB945D6D6CBBEB8"; -const uint8_t JobMonitor::binary_fingerprint[16] = {0xD0,0x03,0x67,0x87,0xE2,0xFC,0x65,0x1C,0xBE,0xB9,0x45,0xD6,0xD6,0xCB,0xBE,0xB8}; - -uint32_t JobMonitor::read(::apache::thrift::protocol::TProtocol* iprot) { - - uint32_t xfer = 0; - std::string fname; - ::apache::thrift::protocol::TType ftype; - int16_t fid; - - xfer += iprot->readStructBegin(fname); - - using ::apache::thrift::protocol::TProtocolException; - - - while (true) - { - xfer += iprot->readFieldBegin(fname, ftype, fid); - if (ftype == ::apache::thrift::protocol::T_STOP) { - break; - } - switch (fid) - { - case 1: - if (ftype == ::apache::thrift::protocol::T_STRING) { - xfer += iprot->readString(this->username); - this->__isset.username = true; - } else { - xfer += iprot->skip(ftype); - } - break; - case 2: - if (ftype == ::apache::thrift::protocol::T_I64) { - xfer += iprot->readI64(this->jobStartedTime); - this->__isset.jobStartedTime = true; - } else { - xfer += iprot->skip(ftype); - } - break; - case 3: - if (ftype == ::apache::thrift::protocol::T_I64) { - xfer += iprot->readI64(this->lastMonitoredTime); - this->__isset.lastMonitoredTime = true; - } else { - xfer += iprot->skip(ftype); - } - break; - case 4: - if (ftype == ::apache::thrift::protocol::T_STRING) { - xfer += iprot->readString(this->hostId); - this->__isset.hostId = true; - } else { - xfer += iprot->skip(ftype); - } - break; - case 5: - if (ftype == ::apache::thrift::protocol::T_MAP) { - { - this->parameters.clear(); - uint32_t _size3; - ::apache::thrift::protocol::TType _ktype4; - ::apache::thrift::protocol::TType _vtype5; - xfer += iprot->readMapBegin(_ktype4, _vtype5, _size3); - uint32_t _i7; - for (_i7 = 0; _i7 < _size3; ++_i7) - { - std::string _key8; - xfer += iprot->readString(_key8); - std::string& _val9 = this->parameters[_key8]; - xfer += iprot->readString(_val9); - } - xfer += iprot->readMapEnd(); - } - this->__isset.parameters = true; - } else { - xfer += iprot->skip(ftype); - } - break; - case 6: - if (ftype == ::apache::thrift::protocol::T_STRING) { - xfer += iprot->readString(this->jobName); - this->__isset.jobName = true; - } else { - xfer += iprot->skip(ftype); - } - break; - case 7: - if (ftype == ::apache::thrift::protocol::T_I32) { - xfer += iprot->readI32(this->failedCount); - this->__isset.failedCount = true; - } else { - xfer += iprot->skip(ftype); - } - break; - default: - xfer += iprot->skip(ftype); - break; - } - xfer += iprot->readFieldEnd(); - } - - xfer += iprot->readStructEnd(); - - return xfer; -} - -uint32_t JobMonitor::write(::apache::thrift::protocol::TProtocol* oprot) const { - uint32_t xfer = 0; - xfer += oprot->writeStructBegin("JobMonitor"); - - if (this->__isset.username) { - xfer += oprot->writeFieldBegin("username", ::apache::thrift::protocol::T_STRING, 1); - xfer += oprot->writeString(this->username); - xfer += oprot->writeFieldEnd(); - } - if (this->__isset.jobStartedTime) { - xfer += oprot->writeFieldBegin("jobStartedTime", ::apache::thrift::protocol::T_I64, 2); - xfer += oprot->writeI64(this->jobStartedTime); - xfer += oprot->writeFieldEnd(); - } - if (this->__isset.lastMonitoredTime) { - xfer += oprot->writeFieldBegin("lastMonitoredTime", ::apache::thrift::protocol::T_I64, 3); - xfer += oprot->writeI64(this->lastMonitoredTime); - xfer += oprot->writeFieldEnd(); - } - if (this->__isset.hostId) { - xfer += oprot->writeFieldBegin("hostId", ::apache::thrift::protocol::T_STRING, 4); - xfer += oprot->writeString(this->hostId); - xfer += oprot->writeFieldEnd(); - } - if (this->__isset.parameters) { - xfer += oprot->writeFieldBegin("parameters", ::apache::thrift::protocol::T_MAP, 5); - { - xfer += oprot->writeMapBegin(::apache::thrift::protocol::T_STRING, ::apache::thrift::protocol::T_STRING, static_cast(this->parameters.size())); - std::map ::const_iterator _iter10; - for (_iter10 = this->parameters.begin(); _iter10 != this->parameters.end(); ++_iter10) - { - xfer += oprot->writeString(_iter10->first); - xfer += oprot->writeString(_iter10->second); - } - xfer += oprot->writeMapEnd(); - } - xfer += oprot->writeFieldEnd(); - } - if (this->__isset.jobName) { - xfer += oprot->writeFieldBegin("jobName", ::apache::thrift::protocol::T_STRING, 6); - xfer += oprot->writeString(this->jobName); - xfer += oprot->writeFieldEnd(); - } - if (this->__isset.failedCount) { - xfer += oprot->writeFieldBegin("failedCount", ::apache::thrift::protocol::T_I32, 7); - xfer += oprot->writeI32(this->failedCount); - xfer += oprot->writeFieldEnd(); - } - xfer += oprot->writeFieldStop(); - xfer += oprot->writeStructEnd(); - return xfer; -} - -void swap(JobMonitor &a, JobMonitor &b) { - using ::std::swap; - swap(a.username, b.username); - swap(a.jobStartedTime, b.jobStartedTime); - swap(a.lastMonitoredTime, b.lastMonitoredTime); - swap(a.hostId, b.hostId); - swap(a.parameters, b.parameters); - swap(a.jobName, b.jobName); - swap(a.failedCount, b.failedCount); - swap(a.__isset, b.__isset); -} - -const char* JobStatusChangeEvent::ascii_fingerprint = "A4467EF21DF0026B864BF2B95C34A774"; -const uint8_t JobStatusChangeEvent::binary_fingerprint[16] = {0xA4,0x46,0x7E,0xF2,0x1D,0xF0,0x02,0x6B,0x86,0x4B,0xF2,0xB9,0x5C,0x34,0xA7,0x74}; +const char* JobStatusChangeEvent::ascii_fingerprint = "8D18A3CD1822DBC67D7BD8CB98E7B4F1"; +const uint8_t JobStatusChangeEvent::binary_fingerprint[16] = {0x8D,0x18,0xA3,0xCD,0x18,0x22,0xDB,0xC6,0x7D,0x7B,0xD8,0xCB,0x98,0xE7,0xB4,0xF1}; uint32_t JobStatusChangeEvent::read(::apache::thrift::protocol::TProtocol* iprot) { @@ -748,7 +577,6 @@ uint32_t JobStatusChangeEvent::read(::apache::thrift::protocol::TProtocol* iprot bool isset_state = false; bool isset_jobIdentity = false; - bool isset_jobMonitor = false; while (true) { @@ -760,9 +588,9 @@ uint32_t JobStatusChangeEvent::read(::apache::thrift::protocol::TProtocol* iprot { case 1: if (ftype == ::apache::thrift::protocol::T_I32) { - int32_t ecast11; - xfer += iprot->readI32(ecast11); - this->state = ( ::apache::airavata::model::workspace::experiment::JobState::type)ecast11; + int32_t ecast3; + xfer += iprot->readI32(ecast3); + this->state = ( ::apache::airavata::model::workspace::experiment::JobState::type)ecast3; isset_state = true; } else { xfer += iprot->skip(ftype); @@ -776,14 +604,6 @@ uint32_t JobStatusChangeEvent::read(::apache::thrift::protocol::TProtocol* iprot xfer += iprot->skip(ftype); } break; - case 3: - if (ftype == ::apache::thrift::protocol::T_STRUCT) { - xfer += this->jobMonitor.read(iprot); - isset_jobMonitor = true; - } else { - xfer += iprot->skip(ftype); - } - break; default: xfer += iprot->skip(ftype); break; @@ -797,8 +617,6 @@ uint32_t JobStatusChangeEvent::read(::apache::thrift::protocol::TProtocol* iprot throw TProtocolException(TProtocolException::INVALID_DATA); if (!isset_jobIdentity) throw TProtocolException(TProtocolException::INVALID_DATA); - if (!isset_jobMonitor) - throw TProtocolException(TProtocolException::INVALID_DATA); return xfer; } @@ -814,10 +632,6 @@ uint32_t JobStatusChangeEvent::write(::apache::thrift::protocol::TProtocol* opro xfer += this->jobIdentity.write(oprot); xfer += oprot->writeFieldEnd(); - xfer += oprot->writeFieldBegin("jobMonitor", ::apache::thrift::protocol::T_STRUCT, 3); - xfer += this->jobMonitor.write(oprot); - xfer += oprot->writeFieldEnd(); - xfer += oprot->writeFieldStop(); xfer += oprot->writeStructEnd(); return xfer; @@ -827,7 +641,6 @@ void swap(JobStatusChangeEvent &a, JobStatusChangeEvent &b) { using ::std::swap; swap(a.state, b.state); swap(a.jobIdentity, b.jobIdentity); - swap(a.jobMonitor, b.jobMonitor); } }}}}} // namespace http://git-wip-us.apache.org/repos/asf/airavata/blob/785394d3/airavata-api/airavata-client-sdks/airavata-cpp-sdk/src/main/resources/lib/airavata/messagingEvents_types.h ---------------------------------------------------------------------- diff --git a/airavata-api/airavata-client-sdks/airavata-cpp-sdk/src/main/resources/lib/airavata/messagingEvents_types.h b/airavata-api/airavata-client-sdks/airavata-cpp-sdk/src/main/resources/lib/airavata/messagingEvents_types.h index baeb37f..c4c07f9 100644 --- a/airavata-api/airavata-client-sdks/airavata-cpp-sdk/src/main/resources/lib/airavata/messagingEvents_types.h +++ b/airavata-api/airavata-client-sdks/airavata-cpp-sdk/src/main/resources/lib/airavata/messagingEvents_types.h @@ -320,124 +320,12 @@ class JobIdentity { void swap(JobIdentity &a, JobIdentity &b); -typedef struct _JobMonitor__isset { - _JobMonitor__isset() : username(false), jobStartedTime(false), lastMonitoredTime(false), hostId(false), parameters(false), jobName(false), failedCount(true) {} - bool username; - bool jobStartedTime; - bool lastMonitoredTime; - bool hostId; - bool parameters; - bool jobName; - bool failedCount; -} _JobMonitor__isset; - -class JobMonitor { - public: - - static const char* ascii_fingerprint; // = "D0036787E2FC651CBEB945D6D6CBBEB8"; - static const uint8_t binary_fingerprint[16]; // = {0xD0,0x03,0x67,0x87,0xE2,0xFC,0x65,0x1C,0xBE,0xB9,0x45,0xD6,0xD6,0xCB,0xBE,0xB8}; - - JobMonitor() : username(), jobStartedTime(0), lastMonitoredTime(0), hostId(), jobName(), failedCount(0) { - } - - virtual ~JobMonitor() throw() {} - - std::string username; - int64_t jobStartedTime; - int64_t lastMonitoredTime; - std::string hostId; - std::map parameters; - std::string jobName; - int32_t failedCount; - - _JobMonitor__isset __isset; - - void __set_username(const std::string& val) { - username = val; - __isset.username = true; - } - - void __set_jobStartedTime(const int64_t val) { - jobStartedTime = val; - __isset.jobStartedTime = true; - } - - void __set_lastMonitoredTime(const int64_t val) { - lastMonitoredTime = val; - __isset.lastMonitoredTime = true; - } - - void __set_hostId(const std::string& val) { - hostId = val; - __isset.hostId = true; - } - - void __set_parameters(const std::map & val) { - parameters = val; - __isset.parameters = true; - } - - void __set_jobName(const std::string& val) { - jobName = val; - __isset.jobName = true; - } - - void __set_failedCount(const int32_t val) { - failedCount = val; - __isset.failedCount = true; - } - - bool operator == (const JobMonitor & rhs) const - { - if (__isset.username != rhs.__isset.username) - return false; - else if (__isset.username && !(username == rhs.username)) - return false; - if (__isset.jobStartedTime != rhs.__isset.jobStartedTime) - return false; - else if (__isset.jobStartedTime && !(jobStartedTime == rhs.jobStartedTime)) - return false; - if (__isset.lastMonitoredTime != rhs.__isset.lastMonitoredTime) - return false; - else if (__isset.lastMonitoredTime && !(lastMonitoredTime == rhs.lastMonitoredTime)) - return false; - if (__isset.hostId != rhs.__isset.hostId) - return false; - else if (__isset.hostId && !(hostId == rhs.hostId)) - return false; - if (__isset.parameters != rhs.__isset.parameters) - return false; - else if (__isset.parameters && !(parameters == rhs.parameters)) - return false; - if (__isset.jobName != rhs.__isset.jobName) - return false; - else if (__isset.jobName && !(jobName == rhs.jobName)) - return false; - if (__isset.failedCount != rhs.__isset.failedCount) - return false; - else if (__isset.failedCount && !(failedCount == rhs.failedCount)) - return false; - return true; - } - bool operator != (const JobMonitor &rhs) const { - return !(*this == rhs); - } - - bool operator < (const JobMonitor & ) const; - - uint32_t read(::apache::thrift::protocol::TProtocol* iprot); - uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const; - -}; - -void swap(JobMonitor &a, JobMonitor &b); - class JobStatusChangeEvent { public: - static const char* ascii_fingerprint; // = "A4467EF21DF0026B864BF2B95C34A774"; - static const uint8_t binary_fingerprint[16]; // = {0xA4,0x46,0x7E,0xF2,0x1D,0xF0,0x02,0x6B,0x86,0x4B,0xF2,0xB9,0x5C,0x34,0xA7,0x74}; + static const char* ascii_fingerprint; // = "8D18A3CD1822DBC67D7BD8CB98E7B4F1"; + static const uint8_t binary_fingerprint[16]; // = {0x8D,0x18,0xA3,0xCD,0x18,0x22,0xDB,0xC6,0x7D,0x7B,0xD8,0xCB,0x98,0xE7,0xB4,0xF1}; JobStatusChangeEvent() : state(( ::apache::airavata::model::workspace::experiment::JobState::type)0) { } @@ -446,7 +334,6 @@ class JobStatusChangeEvent { ::apache::airavata::model::workspace::experiment::JobState::type state; JobIdentity jobIdentity; - JobMonitor jobMonitor; void __set_state(const ::apache::airavata::model::workspace::experiment::JobState::type val) { state = val; @@ -456,18 +343,12 @@ class JobStatusChangeEvent { jobIdentity = val; } - void __set_jobMonitor(const JobMonitor& val) { - jobMonitor = val; - } - bool operator == (const JobStatusChangeEvent & rhs) const { if (!(state == rhs.state)) return false; if (!(jobIdentity == rhs.jobIdentity)) return false; - if (!(jobMonitor == rhs.jobMonitor)) - return false; return true; } bool operator != (const JobStatusChangeEvent &rhs) const { http://git-wip-us.apache.org/repos/asf/airavata/blob/785394d3/airavata-api/airavata-client-sdks/airavata-php-sdk/src/main/resources/lib/Airavata/Model/Messaging/Event/Types.php ---------------------------------------------------------------------- diff --git a/airavata-api/airavata-client-sdks/airavata-php-sdk/src/main/resources/lib/Airavata/Model/Messaging/Event/Types.php b/airavata-api/airavata-client-sdks/airavata-php-sdk/src/main/resources/lib/Airavata/Model/Messaging/Event/Types.php index 569f523..c72d900 100644 --- a/airavata-api/airavata-client-sdks/airavata-php-sdk/src/main/resources/lib/Airavata/Model/Messaging/Event/Types.php +++ b/airavata-api/airavata-client-sdks/airavata-php-sdk/src/main/resources/lib/Airavata/Model/Messaging/Event/Types.php @@ -639,238 +639,11 @@ class JobIdentity { } -class JobMonitor { - static $_TSPEC; - - public $username = null; - public $jobStartedTime = null; - public $lastMonitoredTime = null; - public $hostId = null; - public $parameters = null; - public $jobName = null; - public $failedCount = 0; - - public function __construct($vals=null) { - if (!isset(self::$_TSPEC)) { - self::$_TSPEC = array( - 1 => array( - 'var' => 'username', - 'type' => TType::STRING, - ), - 2 => array( - 'var' => 'jobStartedTime', - 'type' => TType::I64, - ), - 3 => array( - 'var' => 'lastMonitoredTime', - 'type' => TType::I64, - ), - 4 => array( - 'var' => 'hostId', - 'type' => TType::STRING, - ), - 5 => array( - 'var' => 'parameters', - 'type' => TType::MAP, - 'ktype' => TType::STRING, - 'vtype' => TType::STRING, - 'key' => array( - 'type' => TType::STRING, - ), - 'val' => array( - 'type' => TType::STRING, - ), - ), - 6 => array( - 'var' => 'jobName', - 'type' => TType::STRING, - ), - 7 => array( - 'var' => 'failedCount', - 'type' => TType::I32, - ), - ); - } - if (is_array($vals)) { - if (isset($vals['username'])) { - $this->username = $vals['username']; - } - if (isset($vals['jobStartedTime'])) { - $this->jobStartedTime = $vals['jobStartedTime']; - } - if (isset($vals['lastMonitoredTime'])) { - $this->lastMonitoredTime = $vals['lastMonitoredTime']; - } - if (isset($vals['hostId'])) { - $this->hostId = $vals['hostId']; - } - if (isset($vals['parameters'])) { - $this->parameters = $vals['parameters']; - } - if (isset($vals['jobName'])) { - $this->jobName = $vals['jobName']; - } - if (isset($vals['failedCount'])) { - $this->failedCount = $vals['failedCount']; - } - } - } - - public function getName() { - return 'JobMonitor'; - } - - public function read($input) - { - $xfer = 0; - $fname = null; - $ftype = 0; - $fid = 0; - $xfer += $input->readStructBegin($fname); - while (true) - { - $xfer += $input->readFieldBegin($fname, $ftype, $fid); - if ($ftype == TType::STOP) { - break; - } - switch ($fid) - { - case 1: - if ($ftype == TType::STRING) { - $xfer += $input->readString($this->username); - } else { - $xfer += $input->skip($ftype); - } - break; - case 2: - if ($ftype == TType::I64) { - $xfer += $input->readI64($this->jobStartedTime); - } else { - $xfer += $input->skip($ftype); - } - break; - case 3: - if ($ftype == TType::I64) { - $xfer += $input->readI64($this->lastMonitoredTime); - } else { - $xfer += $input->skip($ftype); - } - break; - case 4: - if ($ftype == TType::STRING) { - $xfer += $input->readString($this->hostId); - } else { - $xfer += $input->skip($ftype); - } - break; - case 5: - if ($ftype == TType::MAP) { - $this->parameters = array(); - $_size0 = 0; - $_ktype1 = 0; - $_vtype2 = 0; - $xfer += $input->readMapBegin($_ktype1, $_vtype2, $_size0); - for ($_i4 = 0; $_i4 < $_size0; ++$_i4) - { - $key5 = ''; - $val6 = ''; - $xfer += $input->readString($key5); - $xfer += $input->readString($val6); - $this->parameters[$key5] = $val6; - } - $xfer += $input->readMapEnd(); - } else { - $xfer += $input->skip($ftype); - } - break; - case 6: - if ($ftype == TType::STRING) { - $xfer += $input->readString($this->jobName); - } else { - $xfer += $input->skip($ftype); - } - break; - case 7: - if ($ftype == TType::I32) { - $xfer += $input->readI32($this->failedCount); - } else { - $xfer += $input->skip($ftype); - } - break; - default: - $xfer += $input->skip($ftype); - break; - } - $xfer += $input->readFieldEnd(); - } - $xfer += $input->readStructEnd(); - return $xfer; - } - - public function write($output) { - $xfer = 0; - $xfer += $output->writeStructBegin('JobMonitor'); - if ($this->username !== null) { - $xfer += $output->writeFieldBegin('username', TType::STRING, 1); - $xfer += $output->writeString($this->username); - $xfer += $output->writeFieldEnd(); - } - if ($this->jobStartedTime !== null) { - $xfer += $output->writeFieldBegin('jobStartedTime', TType::I64, 2); - $xfer += $output->writeI64($this->jobStartedTime); - $xfer += $output->writeFieldEnd(); - } - if ($this->lastMonitoredTime !== null) { - $xfer += $output->writeFieldBegin('lastMonitoredTime', TType::I64, 3); - $xfer += $output->writeI64($this->lastMonitoredTime); - $xfer += $output->writeFieldEnd(); - } - if ($this->hostId !== null) { - $xfer += $output->writeFieldBegin('hostId', TType::STRING, 4); - $xfer += $output->writeString($this->hostId); - $xfer += $output->writeFieldEnd(); - } - if ($this->parameters !== null) { - if (!is_array($this->parameters)) { - throw new TProtocolException('Bad type in structure.', TProtocolException::INVALID_DATA); - } - $xfer += $output->writeFieldBegin('parameters', TType::MAP, 5); - { - $output->writeMapBegin(TType::STRING, TType::STRING, count($this->parameters)); - { - foreach ($this->parameters as $kiter7 => $viter8) - { - $xfer += $output->writeString($kiter7); - $xfer += $output->writeString($viter8); - } - } - $output->writeMapEnd(); - } - $xfer += $output->writeFieldEnd(); - } - if ($this->jobName !== null) { - $xfer += $output->writeFieldBegin('jobName', TType::STRING, 6); - $xfer += $output->writeString($this->jobName); - $xfer += $output->writeFieldEnd(); - } - if ($this->failedCount !== null) { - $xfer += $output->writeFieldBegin('failedCount', TType::I32, 7); - $xfer += $output->writeI32($this->failedCount); - $xfer += $output->writeFieldEnd(); - } - $xfer += $output->writeFieldStop(); - $xfer += $output->writeStructEnd(); - return $xfer; - } - -} - class JobStatusChangeEvent { static $_TSPEC; public $state = null; public $jobIdentity = null; - public $jobMonitor = null; public function __construct($vals=null) { if (!isset(self::$_TSPEC)) { @@ -884,11 +657,6 @@ class JobStatusChangeEvent { 'type' => TType::STRUCT, 'class' => '\Airavata\Model\Messaging\Event\JobIdentity', ), - 3 => array( - 'var' => 'jobMonitor', - 'type' => TType::STRUCT, - 'class' => '\Airavata\Model\Messaging\Event\JobMonitor', - ), ); } if (is_array($vals)) { @@ -898,9 +666,6 @@ class JobStatusChangeEvent { if (isset($vals['jobIdentity'])) { $this->jobIdentity = $vals['jobIdentity']; } - if (isset($vals['jobMonitor'])) { - $this->jobMonitor = $vals['jobMonitor']; - } } } @@ -938,14 +703,6 @@ class JobStatusChangeEvent { $xfer += $input->skip($ftype); } break; - case 3: - if ($ftype == TType::STRUCT) { - $this->jobMonitor = new \Airavata\Model\Messaging\Event\JobMonitor(); - $xfer += $this->jobMonitor->read($input); - } else { - $xfer += $input->skip($ftype); - } - break; default: $xfer += $input->skip($ftype); break; @@ -972,14 +729,6 @@ class JobStatusChangeEvent { $xfer += $this->jobIdentity->write($output); $xfer += $output->writeFieldEnd(); } - if ($this->jobMonitor !== null) { - if (!is_object($this->jobMonitor)) { - throw new TProtocolException('Bad type in structure.', TProtocolException::INVALID_DATA); - } - $xfer += $output->writeFieldBegin('jobMonitor', TType::STRUCT, 3); - $xfer += $this->jobMonitor->write($output); - $xfer += $output->writeFieldEnd(); - } $xfer += $output->writeFieldStop(); $xfer += $output->writeStructEnd(); return $xfer; http://git-wip-us.apache.org/repos/asf/airavata/blob/785394d3/airavata-api/airavata-data-models/src/main/java/org/apache/airavata/model/messaging/event/JobStatusChangeEvent.java ---------------------------------------------------------------------- diff --git a/airavata-api/airavata-data-models/src/main/java/org/apache/airavata/model/messaging/event/JobStatusChangeEvent.java b/airavata-api/airavata-data-models/src/main/java/org/apache/airavata/model/messaging/event/JobStatusChangeEvent.java index 3d26458..1dbbaa4 100644 --- a/airavata-api/airavata-data-models/src/main/java/org/apache/airavata/model/messaging/event/JobStatusChangeEvent.java +++ b/airavata-api/airavata-data-models/src/main/java/org/apache/airavata/model/messaging/event/JobStatusChangeEvent.java @@ -54,7 +54,6 @@ import org.slf4j.LoggerFactory; private static final org.apache.thrift.protocol.TField STATE_FIELD_DESC = new org.apache.thrift.protocol.TField("state", org.apache.thrift.protocol.TType.I32, (short)1); private static final org.apache.thrift.protocol.TField JOB_IDENTITY_FIELD_DESC = new org.apache.thrift.protocol.TField("jobIdentity", org.apache.thrift.protocol.TType.STRUCT, (short)2); - private static final org.apache.thrift.protocol.TField JOB_MONITOR_FIELD_DESC = new org.apache.thrift.protocol.TField("jobMonitor", org.apache.thrift.protocol.TType.STRUCT, (short)3); private static final Map, SchemeFactory> schemes = new HashMap, SchemeFactory>(); static { @@ -64,7 +63,6 @@ import org.slf4j.LoggerFactory; private org.apache.airavata.model.workspace.experiment.JobState state; // required private JobIdentity jobIdentity; // required - private JobMonitor jobMonitor; // required /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */ @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum { @@ -73,8 +71,7 @@ import org.slf4j.LoggerFactory; * @see org.apache.airavata.model.workspace.experiment.JobState */ STATE((short)1, "state"), - JOB_IDENTITY((short)2, "jobIdentity"), - JOB_MONITOR((short)3, "jobMonitor"); + JOB_IDENTITY((short)2, "jobIdentity"); private static final Map byName = new HashMap(); @@ -93,8 +90,6 @@ import org.slf4j.LoggerFactory; return STATE; case 2: // JOB_IDENTITY return JOB_IDENTITY; - case 3: // JOB_MONITOR - return JOB_MONITOR; default: return null; } @@ -142,8 +137,6 @@ import org.slf4j.LoggerFactory; new org.apache.thrift.meta_data.EnumMetaData(org.apache.thrift.protocol.TType.ENUM, org.apache.airavata.model.workspace.experiment.JobState.class))); tmpMap.put(_Fields.JOB_IDENTITY, new org.apache.thrift.meta_data.FieldMetaData("jobIdentity", org.apache.thrift.TFieldRequirementType.REQUIRED, new org.apache.thrift.meta_data.StructMetaData(org.apache.thrift.protocol.TType.STRUCT, JobIdentity.class))); - tmpMap.put(_Fields.JOB_MONITOR, new org.apache.thrift.meta_data.FieldMetaData("jobMonitor", org.apache.thrift.TFieldRequirementType.REQUIRED, - new org.apache.thrift.meta_data.StructMetaData(org.apache.thrift.protocol.TType.STRUCT, JobMonitor.class))); metaDataMap = Collections.unmodifiableMap(tmpMap); org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(JobStatusChangeEvent.class, metaDataMap); } @@ -153,13 +146,11 @@ import org.slf4j.LoggerFactory; public JobStatusChangeEvent( org.apache.airavata.model.workspace.experiment.JobState state, - JobIdentity jobIdentity, - JobMonitor jobMonitor) + JobIdentity jobIdentity) { this(); this.state = state; this.jobIdentity = jobIdentity; - this.jobMonitor = jobMonitor; } /** @@ -172,9 +163,6 @@ import org.slf4j.LoggerFactory; if (other.isSetJobIdentity()) { this.jobIdentity = new JobIdentity(other.jobIdentity); } - if (other.isSetJobMonitor()) { - this.jobMonitor = new JobMonitor(other.jobMonitor); - } } public JobStatusChangeEvent deepCopy() { @@ -185,7 +173,6 @@ import org.slf4j.LoggerFactory; public void clear() { this.state = null; this.jobIdentity = null; - this.jobMonitor = null; } /** @@ -242,29 +229,6 @@ import org.slf4j.LoggerFactory; } } - public JobMonitor getJobMonitor() { - return this.jobMonitor; - } - - public void setJobMonitor(JobMonitor jobMonitor) { - this.jobMonitor = jobMonitor; - } - - public void unsetJobMonitor() { - this.jobMonitor = null; - } - - /** Returns true if field jobMonitor is set (has been assigned a value) and false otherwise */ - public boolean isSetJobMonitor() { - return this.jobMonitor != null; - } - - public void setJobMonitorIsSet(boolean value) { - if (!value) { - this.jobMonitor = null; - } - } - public void setFieldValue(_Fields field, Object value) { switch (field) { case STATE: @@ -283,14 +247,6 @@ import org.slf4j.LoggerFactory; } break; - case JOB_MONITOR: - if (value == null) { - unsetJobMonitor(); - } else { - setJobMonitor((JobMonitor)value); - } - break; - } } @@ -302,9 +258,6 @@ import org.slf4j.LoggerFactory; case JOB_IDENTITY: return getJobIdentity(); - case JOB_MONITOR: - return getJobMonitor(); - } throw new IllegalStateException(); } @@ -320,8 +273,6 @@ import org.slf4j.LoggerFactory; return isSetState(); case JOB_IDENTITY: return isSetJobIdentity(); - case JOB_MONITOR: - return isSetJobMonitor(); } throw new IllegalStateException(); } @@ -357,15 +308,6 @@ import org.slf4j.LoggerFactory; return false; } - boolean this_present_jobMonitor = true && this.isSetJobMonitor(); - boolean that_present_jobMonitor = true && that.isSetJobMonitor(); - if (this_present_jobMonitor || that_present_jobMonitor) { - if (!(this_present_jobMonitor && that_present_jobMonitor)) - return false; - if (!this.jobMonitor.equals(that.jobMonitor)) - return false; - } - return true; } @@ -402,16 +344,6 @@ import org.slf4j.LoggerFactory; return lastComparison; } } - lastComparison = Boolean.valueOf(isSetJobMonitor()).compareTo(other.isSetJobMonitor()); - if (lastComparison != 0) { - return lastComparison; - } - if (isSetJobMonitor()) { - lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.jobMonitor, other.jobMonitor); - if (lastComparison != 0) { - return lastComparison; - } - } return 0; } @@ -447,14 +379,6 @@ import org.slf4j.LoggerFactory; sb.append(this.jobIdentity); } first = false; - if (!first) sb.append(", "); - sb.append("jobMonitor:"); - if (this.jobMonitor == null) { - sb.append("null"); - } else { - sb.append(this.jobMonitor); - } - first = false; sb.append(")"); return sb.toString(); } @@ -469,17 +393,10 @@ import org.slf4j.LoggerFactory; throw new org.apache.thrift.protocol.TProtocolException("Required field 'jobIdentity' is unset! Struct:" + toString()); } - if (!isSetJobMonitor()) { - throw new org.apache.thrift.protocol.TProtocolException("Required field 'jobMonitor' is unset! Struct:" + toString()); - } - // check for sub-struct validity if (jobIdentity != null) { jobIdentity.validate(); } - if (jobMonitor != null) { - jobMonitor.validate(); - } } private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException { @@ -533,15 +450,6 @@ import org.slf4j.LoggerFactory; org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; - case 3: // JOB_MONITOR - if (schemeField.type == org.apache.thrift.protocol.TType.STRUCT) { - struct.jobMonitor = new JobMonitor(); - struct.jobMonitor.read(iprot); - struct.setJobMonitorIsSet(true); - } else { - org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); - } - break; default: org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } @@ -565,11 +473,6 @@ import org.slf4j.LoggerFactory; struct.jobIdentity.write(oprot); oprot.writeFieldEnd(); } - if (struct.jobMonitor != null) { - oprot.writeFieldBegin(JOB_MONITOR_FIELD_DESC); - struct.jobMonitor.write(oprot); - oprot.writeFieldEnd(); - } oprot.writeFieldStop(); oprot.writeStructEnd(); } @@ -589,7 +492,6 @@ import org.slf4j.LoggerFactory; TTupleProtocol oprot = (TTupleProtocol) prot; oprot.writeI32(struct.state.getValue()); struct.jobIdentity.write(oprot); - struct.jobMonitor.write(oprot); } @Override @@ -600,9 +502,6 @@ import org.slf4j.LoggerFactory; struct.jobIdentity = new JobIdentity(); struct.jobIdentity.read(iprot); struct.setJobIdentityIsSet(true); - struct.jobMonitor = new JobMonitor(); - struct.jobMonitor.read(iprot); - struct.setJobMonitorIsSet(true); } } http://git-wip-us.apache.org/repos/asf/airavata/blob/785394d3/airavata-api/thrift-interface-descriptions/messagingEvents.thrift ---------------------------------------------------------------------- diff --git a/airavata-api/thrift-interface-descriptions/messagingEvents.thrift b/airavata-api/thrift-interface-descriptions/messagingEvents.thrift index a9be5bd..ebe1c57 100644 --- a/airavata-api/thrift-interface-descriptions/messagingEvents.thrift +++ b/airavata-api/thrift-interface-descriptions/messagingEvents.thrift @@ -57,22 +57,22 @@ struct JobIdentity { 4: required string experimentId; } -struct JobMonitor { - 1: optional string username; - 2: optional i64 jobStartedTime; - 3: optional i64 lastMonitoredTime; - 4: optional string hostId; - 5: optional map parameters; - 6: optional string jobName; - 7: optional i32 failedCount = 0; - // FIXME - Job execution context - //8: - } +//struct JobMonitor { +// 1: optional string username; +// 2: optional i64 jobStartedTime; +// 3: optional i64 lastMonitoredTime; +// 4: optional string hostId; +// 5: optional map parameters; +// 6: optional string jobName; +// 7: optional i32 failedCount = 0; +// // FIXME - Job execution context +// //8: +// } struct JobStatusChangeEvent { 1: required experimentModel.JobState state; 2: required JobIdentity jobIdentity; - 3: required JobMonitor jobMonitor; +// 3: required JobMonitor jobMonitor; } http://git-wip-us.apache.org/repos/asf/airavata/blob/785394d3/modules/configuration/server/src/main/resources/airavata-server.properties ---------------------------------------------------------------------- diff --git a/modules/configuration/server/src/main/resources/airavata-server.properties b/modules/configuration/server/src/main/resources/airavata-server.properties index 589c3d1..ebf5350 100644 --- a/modules/configuration/server/src/main/resources/airavata-server.properties +++ b/modules/configuration/server/src/main/resources/airavata-server.properties @@ -187,6 +187,8 @@ amqp.hosts=info1.dyn.teragrid.org,info2.dyn.teragrid.org proxy.file.path=/Users/lahirugunathilake/Downloads/x509up_u503876 connection.name=xsede activity.listeners=org.apache.airavata.gfac.core.monitor.AiravataJobStatusUpdator,org.apache.airavata.gfac.core.monitor.AiravataTaskStatusUpdator,org.apache.airavata.gfac.core.monitor.AiravataWorkflowNodeStatusUpdator,org.apache.airavata.api.server.listener.AiravataExperimentStatusUpdator,org.apache.airavata.gfac.core.monitor.GfacInternalStatusUpdator,org.apache.airavata.workflow.engine.util.ProxyMonitorPublisher +#publisher +activity.publisher=org.apache.airavata.messaging.core.impl.AiravataRabbitMQPublisher ###---------------------------Orchestrator module Configurations---------------------------### #job.submitter=org.apache.airavata.orchestrator.core.impl.GFACEmbeddedJobSubmitter http://git-wip-us.apache.org/repos/asf/airavata/blob/785394d3/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/monitor/AiravataJobStatusUpdator.java ---------------------------------------------------------------------- diff --git a/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/monitor/AiravataJobStatusUpdator.java b/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/monitor/AiravataJobStatusUpdator.java index 80fa0d9..473debd 100644 --- a/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/monitor/AiravataJobStatusUpdator.java +++ b/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/monitor/AiravataJobStatusUpdator.java @@ -24,8 +24,7 @@ import java.util.Calendar; import org.apache.airavata.common.utils.MonitorPublisher; import org.apache.airavata.common.utils.listener.AbstractActivityListener; -import org.apache.airavata.gfac.core.monitor.state.JobStatusChangeRequest; -import org.apache.airavata.gfac.core.monitor.state.JobStatusChangedEvent; +import org.apache.airavata.model.messaging.event.JobStatusChangeEvent; import org.apache.airavata.model.workspace.experiment.JobDetails; import org.apache.airavata.model.workspace.experiment.JobState; import org.apache.airavata.registry.cpi.CompositeIdentifier; @@ -54,18 +53,18 @@ public class AiravataJobStatusUpdator implements AbstractActivityListener { @Subscribe - public void updateRegistry(JobStatusChangeRequest jobStatus) { + public void updateRegistry(JobStatusChangeEvent jobStatus) { /* Here we need to parse the jobStatus message and update the registry accordingly, for now we are just printing to standard Out */ JobState state = jobStatus.getState(); if (state != null) { try { - String taskID = jobStatus.getIdentity().getTaskId(); - String jobID = jobStatus.getIdentity().getJobId(); + String taskID = jobStatus.getJobIdentity().getTaskId(); + String jobID = jobStatus.getJobIdentity().getJobId(); updateJobStatus(taskID, jobID, state); - logger.debug("Publishing job status for "+jobStatus.getIdentity().getJobId()+":"+state.toString()); - monitorPublisher.publish(new JobStatusChangedEvent(jobStatus.getMonitorID(),jobStatus.getIdentity(),state)); + logger.debug("Publishing job status for "+jobStatus.getJobIdentity().getJobId()+":"+state.toString()); + monitorPublisher.publish(new JobStatusChangeEvent(jobStatus.getState(), jobStatus.getJobIdentity())); } catch (Exception e) { logger.error("Error persisting data" + e.getLocalizedMessage(), e); } http://git-wip-us.apache.org/repos/asf/airavata/blob/785394d3/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/monitor/AiravataTaskStatusUpdator.java ---------------------------------------------------------------------- diff --git a/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/monitor/AiravataTaskStatusUpdator.java b/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/monitor/AiravataTaskStatusUpdator.java index 1e68bdc..56fbb1c 100644 --- a/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/monitor/AiravataTaskStatusUpdator.java +++ b/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/monitor/AiravataTaskStatusUpdator.java @@ -24,9 +24,10 @@ import java.util.Calendar; import org.apache.airavata.common.utils.MonitorPublisher; import org.apache.airavata.common.utils.listener.AbstractActivityListener; -import org.apache.airavata.gfac.core.monitor.state.JobStatusChangedEvent; import org.apache.airavata.gfac.core.monitor.state.TaskStatusChangeRequest; import org.apache.airavata.gfac.core.monitor.state.TaskStatusChangedEvent; +import org.apache.airavata.model.messaging.event.*; +import org.apache.airavata.model.messaging.event.TaskIdentity; import org.apache.airavata.model.workspace.experiment.TaskDetails; import org.apache.airavata.model.workspace.experiment.TaskState; import org.apache.airavata.registry.cpi.Registry; @@ -63,7 +64,7 @@ public class AiravataTaskStatusUpdator implements AbstractActivityListener { } @Subscribe - public void setupTaskStatus(JobStatusChangedEvent jobStatus){ + public void setupTaskStatus(JobStatusChangeEvent jobStatus){ TaskState state=TaskState.UNKNOWN; switch(jobStatus.getState()){ case ACTIVE: @@ -88,9 +89,12 @@ public class AiravataTaskStatusUpdator implements AbstractActivityListener { break; } try { - updateTaskStatus(jobStatus.getIdentity().getTaskId(), state); - logger.debug("Publishing task status for "+jobStatus.getIdentity().getTaskId()+":"+state.toString()); - monitorPublisher.publish(new TaskStatusChangedEvent(jobStatus.getIdentity(),state)); + updateTaskStatus(jobStatus.getJobIdentity().getTaskId(), state); + logger.debug("Publishing task status for "+jobStatus.getJobIdentity().getTaskId()+":"+state.toString()); + TaskIdentity taskIdentity = new TaskIdentity(jobStatus.getJobIdentity().getTaskId(), + jobStatus.getJobIdentity().getWorkflowNodeId(), + jobStatus.getJobIdentity().getExperimentId()); + monitorPublisher.publish(new TaskStatusChangeEvent(state, taskIdentity)); } catch (Exception e) { logger.error("Error persisting data" + e.getLocalizedMessage(), e); } http://git-wip-us.apache.org/repos/asf/airavata/blob/785394d3/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/monitor/AiravataWorkflowNodeStatusUpdator.java ---------------------------------------------------------------------- diff --git a/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/monitor/AiravataWorkflowNodeStatusUpdator.java b/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/monitor/AiravataWorkflowNodeStatusUpdator.java index 133ff73..e0b8f9e 100644 --- a/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/monitor/AiravataWorkflowNodeStatusUpdator.java +++ b/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/monitor/AiravataWorkflowNodeStatusUpdator.java @@ -24,8 +24,9 @@ import java.util.Calendar; import org.apache.airavata.common.utils.MonitorPublisher; import org.apache.airavata.common.utils.listener.AbstractActivityListener; -import org.apache.airavata.gfac.core.monitor.state.TaskStatusChangedEvent; -import org.apache.airavata.gfac.core.monitor.state.WorkflowNodeStatusChangedEvent; +import org.apache.airavata.model.messaging.event.TaskStatusChangeEvent; +import org.apache.airavata.model.messaging.event.WorkflowIdentity; +import org.apache.airavata.model.messaging.event.WorkflowNodeStatusChangeEvent; import org.apache.airavata.model.workspace.experiment.WorkflowNodeDetails; import org.apache.airavata.model.workspace.experiment.WorkflowNodeState; import org.apache.airavata.model.workspace.experiment.WorkflowNodeStatus; @@ -52,7 +53,7 @@ public class AiravataWorkflowNodeStatusUpdator implements AbstractActivityListen } @Subscribe - public void setupWorkflowNodeStatus(TaskStatusChangedEvent taskStatus){ + public void setupWorkflowNodeStatus(TaskStatusChangeEvent taskStatus){ WorkflowNodeState state=WorkflowNodeState.UNKNOWN; switch(taskStatus.getState()){ case CANCELED: @@ -73,9 +74,10 @@ public class AiravataWorkflowNodeStatusUpdator implements AbstractActivityListen break; } try { - updateWorkflowNodeStatus(taskStatus.getIdentity().getWorkflowNodeID(), state); - logger.debug("Publishing workflow node status for "+taskStatus.getIdentity().getWorkflowNodeID()+":"+state.toString()); - monitorPublisher.publish(new WorkflowNodeStatusChangedEvent(taskStatus.getIdentity(),state)); + updateWorkflowNodeStatus(taskStatus.getTaskIdentity().getWorkflowNodeId(), state); + logger.debug("Publishing workflow node status for "+taskStatus.getTaskIdentity().getWorkflowNodeId()+":"+state.toString()); + WorkflowIdentity workflowIdentity = new WorkflowIdentity(taskStatus.getTaskIdentity().getWorkflowNodeId(), taskStatus.getTaskIdentity().getExperimentId()); + monitorPublisher.publish(new WorkflowNodeStatusChangeEvent(state, workflowIdentity)); } catch (Exception e) { logger.error("Error persisting data" + e.getLocalizedMessage(), e); } http://git-wip-us.apache.org/repos/asf/airavata/blob/785394d3/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/monitor/ExperimentIdentity.java ---------------------------------------------------------------------- diff --git a/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/monitor/ExperimentIdentity.java b/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/monitor/ExperimentIdentity.java index 5993101..e8d22f7 100644 --- a/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/monitor/ExperimentIdentity.java +++ b/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/monitor/ExperimentIdentity.java @@ -1,36 +1,36 @@ -/* - * - * 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.gfac.core.monitor; - -public class ExperimentIdentity { - private String experimentID; - public ExperimentIdentity(String experimentId) { - setExperimentID(experimentId); - } - public String getExperimentID() { - return experimentID; - } - - public void setExperimentID(String experimentID) { - this.experimentID = experimentID; - } -} +///* +// * +// * 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.gfac.core.monitor; +// +//public class ExperimentIdentity { +// private String experimentID; +// public ExperimentIdentity(String experimentId) { +// setExperimentID(experimentId); +// } +// public String getExperimentID() { +// return experimentID; +// } +// +// public void setExperimentID(String experimentID) { +// this.experimentID = experimentID; +// } +//} http://git-wip-us.apache.org/repos/asf/airavata/blob/785394d3/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/monitor/JobIdentity.java ---------------------------------------------------------------------- diff --git a/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/monitor/JobIdentity.java b/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/monitor/JobIdentity.java index cea7fa7..1773ff1 100644 --- a/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/monitor/JobIdentity.java +++ b/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/monitor/JobIdentity.java @@ -1,39 +1,39 @@ -/* - * - * 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.gfac.core.monitor; - -public class JobIdentity extends TaskIdentity { - private String jobId; - - public JobIdentity(String experimentId, String workflowNodeId, String taskId, String jobId) { - super(experimentId,workflowNodeId,taskId); - setJobId(jobId); - } - - public String getJobId() { - return jobId; - } - - public void setJobId(String jobId) { - this.jobId = jobId; - } -} +///* +// * +// * 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.gfac.core.monitor; +// +//public class JobIdentity extends TaskIdentity { +// private String jobId; +// +// public JobIdentity(String experimentId, String workflowNodeId, String taskId, String jobId) { +// super(experimentId,workflowNodeId,taskId); +// setJobId(jobId); +// } +// +// public String getJobId() { +// return jobId; +// } +// +// public void setJobId(String jobId) { +// this.jobId = jobId; +// } +//} http://git-wip-us.apache.org/repos/asf/airavata/blob/785394d3/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/monitor/TaskIdentity.java ---------------------------------------------------------------------- diff --git a/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/monitor/TaskIdentity.java b/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/monitor/TaskIdentity.java index 2f2d6c5..8448437 100644 --- a/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/monitor/TaskIdentity.java +++ b/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/monitor/TaskIdentity.java @@ -1,38 +1,38 @@ -/* - * - * 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.gfac.core.monitor; - -public class TaskIdentity extends WorkflowNodeIdentity { - private String taskId; - - public TaskIdentity(String experimentId, String workflowNodeId, String taskId) { - super(experimentId,workflowNodeId); - setTaskId(taskId); - } - public String getTaskId() { - return taskId; - } - - public void setTaskId(String taskId) { - this.taskId = taskId; - } -} +///* +// * +// * 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.gfac.core.monitor; +// +//public class TaskIdentity extends WorkflowNodeIdentity { +// private String taskId; +// +// public TaskIdentity(String experimentId, String workflowNodeId, String taskId) { +// super(experimentId,workflowNodeId); +// setTaskId(taskId); +// } +// public String getTaskId() { +// return taskId; +// } +// +// public void setTaskId(String taskId) { +// this.taskId = taskId; +// } +//} http://git-wip-us.apache.org/repos/asf/airavata/blob/785394d3/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/monitor/WorkflowNodeIdentity.java ---------------------------------------------------------------------- diff --git a/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/monitor/WorkflowNodeIdentity.java b/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/monitor/WorkflowNodeIdentity.java index 71a8f14..ebdc372 100644 --- a/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/monitor/WorkflowNodeIdentity.java +++ b/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/monitor/WorkflowNodeIdentity.java @@ -1,37 +1,37 @@ -/* - * - * 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.gfac.core.monitor; - -public class WorkflowNodeIdentity extends ExperimentIdentity { - private String workflowNodeID; - public WorkflowNodeIdentity(String experimentId, String workflowNodeId) { - super(experimentId); - setWorkflowNodeID(workflowNodeId); - } - public String getWorkflowNodeID() { - return workflowNodeID; - } - - public void setWorkflowNodeID(String workflowNodeID) { - this.workflowNodeID = workflowNodeID; - } -} +///* +// * +// * 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.gfac.core.monitor; +// +//public class WorkflowNodeIdentity extends ExperimentIdentity { +// private String workflowNodeID; +// public WorkflowNodeIdentity(String experimentId, String workflowNodeId) { +// super(experimentId); +// setWorkflowNodeID(workflowNodeId); +// } +// public String getWorkflowNodeID() { +// return workflowNodeID; +// } +// +// public void setWorkflowNodeID(String workflowNodeID) { +// this.workflowNodeID = workflowNodeID; +// } +//} http://git-wip-us.apache.org/repos/asf/airavata/blob/785394d3/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/monitor/state/JobStatusChangeRequest.java ---------------------------------------------------------------------- diff --git a/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/monitor/state/JobStatusChangeRequest.java b/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/monitor/state/JobStatusChangeRequest.java index e4b55f5..2530ff8 100644 --- a/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/monitor/state/JobStatusChangeRequest.java +++ b/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/monitor/state/JobStatusChangeRequest.java @@ -1,81 +1,81 @@ -/* - * - * 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.gfac.core.monitor.state; - -import org.apache.airavata.common.utils.listener.AbstractStateChangeRequest; -import org.apache.airavata.gfac.core.monitor.JobIdentity; -import org.apache.airavata.gfac.core.monitor.MonitorID; -import org.apache.airavata.model.workspace.experiment.JobState; - -/** - * This is the primary job state object used in - * through out the monitor module. This use airavata-data-model JobState enum - * Ideally after processing each event or monitoring message from remote system - * Each monitoring implementation has to return this object with a state and - * the monitoring ID - */ -public class JobStatusChangeRequest extends AbstractStateChangeRequest { - private JobState state; - private JobIdentity identity; - - private MonitorID monitorID; - - // this constructor can be used in Qstat monitor to handle errors - public JobStatusChangeRequest() { - } - - public JobStatusChangeRequest(MonitorID monitorID) { - setIdentity(new JobIdentity(monitorID.getExperimentID(),monitorID.getWorkflowNodeID(), - monitorID.getTaskID(),monitorID.getJobID())); - setMonitorID(monitorID); - this.state = monitorID.getStatus(); - } - public JobStatusChangeRequest(MonitorID monitorID, JobIdentity jobId, JobState state) { - setIdentity(jobId); - setMonitorID(monitorID); - this.state = state; - } - - public JobState getState() { - return state; - } - - public void setState(JobState state) { - this.state = state; - } - - public JobIdentity getIdentity() { - return identity; - } - - public void setIdentity(JobIdentity identity) { - this.identity = identity; - } - - public MonitorID getMonitorID() { - return monitorID; - } - - public void setMonitorID(MonitorID monitorID) { - this.monitorID = monitorID; - } - -} +///* +// * +// * 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.gfac.core.monitor.state; +// +//import org.apache.airavata.common.utils.listener.AbstractStateChangeRequest; +//import org.apache.airavata.gfac.core.monitor.JobIdentity; +//import org.apache.airavata.gfac.core.monitor.MonitorID; +//import org.apache.airavata.model.workspace.experiment.JobState; +// +///** +// * This is the primary job state object used in +// * through out the monitor module. This use airavata-data-model JobState enum +// * Ideally after processing each event or monitoring message from remote system +// * Each monitoring implementation has to return this object with a state and +// * the monitoring ID +// */ +//public class JobStatusChangeRequest extends AbstractStateChangeRequest { +// private JobState state; +// private JobIdentity identity; +// +// private MonitorID monitorID; +// +// // this constructor can be used in Qstat monitor to handle errors +// public JobStatusChangeRequest() { +// } +// +// public JobStatusChangeRequest(MonitorID monitorID) { +// setIdentity(new JobIdentity(monitorID.getExperimentID(),monitorID.getWorkflowNodeID(), +// monitorID.getTaskID(),monitorID.getJobID())); +// setMonitorID(monitorID); +// this.state = monitorID.getStatus(); +// } +// public JobStatusChangeRequest(MonitorID monitorID, JobIdentity jobId, JobState state) { +// setIdentity(jobId); +// setMonitorID(monitorID); +// this.state = state; +// } +// +// public JobState getState() { +// return state; +// } +// +// public void setState(JobState state) { +// this.state = state; +// } +// +// public JobIdentity getIdentity() { +// return identity; +// } +// +// public void setIdentity(JobIdentity identity) { +// this.identity = identity; +// } +// +// public MonitorID getMonitorID() { +// return monitorID; +// } +// +// public void setMonitorID(MonitorID monitorID) { +// this.monitorID = monitorID; +// } +// +//} http://git-wip-us.apache.org/repos/asf/airavata/blob/785394d3/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/monitor/state/JobStatusChangedEvent.java ---------------------------------------------------------------------- diff --git a/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/monitor/state/JobStatusChangedEvent.java b/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/monitor/state/JobStatusChangedEvent.java index 9589bb1..b5ccf1c 100644 --- a/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/monitor/state/JobStatusChangedEvent.java +++ b/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/monitor/state/JobStatusChangedEvent.java @@ -1,81 +1,81 @@ -/* - * - * 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.gfac.core.monitor.state; - -import org.apache.airavata.common.utils.listener.AbstractStateChangeRequest; -import org.apache.airavata.gfac.core.monitor.JobIdentity; -import org.apache.airavata.gfac.core.monitor.MonitorID; -import org.apache.airavata.model.workspace.experiment.JobState; - -/** - * This is the primary job state object used in - * through out the monitor module. This use airavata-data-model JobState enum - * Ideally after processing each event or monitoring message from remote system - * Each monitoring implementation has to return this object with a state and - * the monitoring ID - */ -public class JobStatusChangedEvent extends AbstractStateChangeRequest { - private JobState state; - private JobIdentity identity; - - private MonitorID monitorID; - - // this constructor can be used in Qstat monitor to handle errors - public JobStatusChangedEvent() { - } - - public JobStatusChangedEvent(MonitorID monitorID) { - setIdentity(new JobIdentity(monitorID.getExperimentID(),monitorID.getWorkflowNodeID(), - monitorID.getTaskID(),monitorID.getJobID())); - setMonitorID(monitorID); - this.state = monitorID.getStatus(); - } - public JobStatusChangedEvent(MonitorID monitorID, JobIdentity jobId, JobState state) { - setIdentity(jobId); - setMonitorID(monitorID); - this.state = state; - } - - public JobState getState() { - return state; - } - - public void setState(JobState state) { - this.state = state; - } - - public JobIdentity getIdentity() { - return identity; - } - - public void setIdentity(JobIdentity identity) { - this.identity = identity; - } - - public MonitorID getMonitorID() { - return monitorID; - } - - public void setMonitorID(MonitorID monitorID) { - this.monitorID = monitorID; - } - -} +///* +// * +// * 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.gfac.core.monitor.state; +// +//import org.apache.airavata.common.utils.listener.AbstractStateChangeRequest; +//import org.apache.airavata.gfac.core.monitor.JobIdentity; +//import org.apache.airavata.gfac.core.monitor.MonitorID; +//import org.apache.airavata.model.workspace.experiment.JobState; +// +///** +// * This is the primary job state object used in +// * through out the monitor module. This use airavata-data-model JobState enum +// * Ideally after processing each event or monitoring message from remote system +// * Each monitoring implementation has to return this object with a state and +// * the monitoring ID +// */ +//public class JobStatusChangedEvent extends AbstractStateChangeRequest { +// private JobState state; +// private JobIdentity identity; +// +// private MonitorID monitorID; +// +// // this constructor can be used in Qstat monitor to handle errors +// public JobStatusChangedEvent() { +// } +// +// public JobStatusChangedEvent(MonitorID monitorID) { +// setIdentity(new JobIdentity(monitorID.getExperimentID(),monitorID.getWorkflowNodeID(), +// monitorID.getTaskID(),monitorID.getJobID())); +// setMonitorID(monitorID); +// this.state = monitorID.getStatus(); +// } +// public JobStatusChangedEvent(MonitorID monitorID, JobIdentity jobId, JobState state) { +// setIdentity(jobId); +// setMonitorID(monitorID); +// this.state = state; +// } +// +// public JobState getState() { +// return state; +// } +// +// public void setState(JobState state) { +// this.state = state; +// } +// +// public JobIdentity getIdentity() { +// return identity; +// } +// +// public void setIdentity(JobIdentity identity) { +// this.identity = identity; +// } +// +// public MonitorID getMonitorID() { +// return monitorID; +// } +// +// public void setMonitorID(MonitorID monitorID) { +// this.monitorID = monitorID; +// } +// +//} http://git-wip-us.apache.org/repos/asf/airavata/blob/785394d3/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/monitor/state/TaskOutputDataChangedEvent.java ---------------------------------------------------------------------- diff --git a/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/monitor/state/TaskOutputDataChangedEvent.java b/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/monitor/state/TaskOutputDataChangedEvent.java index 8f10637..cccca30 100644 --- a/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/monitor/state/TaskOutputDataChangedEvent.java +++ b/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/monitor/state/TaskOutputDataChangedEvent.java @@ -1,64 +1,64 @@ -/* - * - * 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.gfac.core.monitor.state; - -import java.util.List; - -import org.apache.airavata.common.utils.listener.AbstractStateChangeRequest; -import org.apache.airavata.gfac.core.monitor.TaskIdentity; -import org.apache.airavata.model.workspace.experiment.DataObjectType; - -/** - * This is the primary job state object used in - * through out the monitor module. This use airavata-data-model JobState enum - * Ideally after processing each event or monitoring message from remote system - * Each monitoring implementation has to return this object with a state and - * the monitoring ID - */ -public class TaskOutputDataChangedEvent extends AbstractStateChangeRequest { - private List output; - private TaskIdentity identity; - // this constructor can be used in Qstat monitor to handle errors - public TaskOutputDataChangedEvent() { - } - - public TaskOutputDataChangedEvent(TaskIdentity taskIdentity, List output) { - this.output = output; - setIdentity(taskIdentity); - } - - public TaskIdentity getIdentity() { - return identity; - } - - public void setIdentity(TaskIdentity identity) { - this.identity = identity; - } - - public List getOutput() { - return output; - } - - public void setOutput(List output) { - this.output = output; - } - -} +///* +// * +// * 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.gfac.core.monitor.state; +// +//import java.util.List; +// +//import org.apache.airavata.common.utils.listener.AbstractStateChangeRequest; +//import org.apache.airavata.gfac.core.monitor.TaskIdentity; +//import org.apache.airavata.model.workspace.experiment.DataObjectType; +// +///** +// * This is the primary job state object used in +// * through out the monitor module. This use airavata-data-model JobState enum +// * Ideally after processing each event or monitoring message from remote system +// * Each monitoring implementation has to return this object with a state and +// * the monitoring ID +// */ +//public class TaskOutputDataChangedEvent extends AbstractStateChangeRequest { +// private List output; +// private TaskIdentity identity; +// // this constructor can be used in Qstat monitor to handle errors +// public TaskOutputDataChangedEvent() { +// } +// +// public TaskOutputDataChangedEvent(TaskIdentity taskIdentity, List output) { +// this.output = output; +// setIdentity(taskIdentity); +// } +// +// public TaskIdentity getIdentity() { +// return identity; +// } +// +// public void setIdentity(TaskIdentity identity) { +// this.identity = identity; +// } +// +// public List getOutput() { +// return output; +// } +// +// public void setOutput(List output) { +// this.output = output; +// } +// +//}