def CreateTransferFileList(job_state, **kwargs): """ Function prepares job for staging out :param job_state: (JobState) decoded job state file mandatory Other params can be passed into functions: 1. To overwrite environment variables: Unused parameters are ommited. :return: 1. (integer) return code 2. (string) logfile path 3. (string) dir with files 2. (list) list of files to be transferred """ currentDir = os.getcwd() pUtil.chdir(job_state.site.workdir) logfile = "%s/%s" % (job_state.site.workdir, job_state.job.logFile) logfile = ( os.path.abspath(logfile) if os.path.isfile(logfile) and not pUtil.isLogfileCopied(job_state.site.workdir) else "" ) remaining_files = [] filesDir = "" if os.path.isdir(job_state.job.datadir): pUtil.chdir(job_state.job.datadir) remaining_files = pUtil.getRemainingOutputFiles(job_state.job.outFiles) if not remaining_files: remaining_files = [] filesDir = os.path.abspath(job_state.job.datadir) pUtil.chdir(currentDir) return ReturnCode.OK, logfile, filesDir, remaining_files
def CreateTransferFileList(job_state, **kwargs): """ Function prepares job for staging out :param job_state: (JobState) decoded job state file mandatory Other params can be passed into functions: 1. To overwrite environment variables: Unused parameters are ommited. :return: 1. (integer) return code 2. (string) logfile path 3. (string) dir with files 2. (list) list of files to be transferred """ currentDir = os.getcwd() pUtil.chdir(job_state.site.workdir) logfile = "%s/%s" % (job_state.site.workdir, job_state.job.logFile) logfile = os.path.abspath(logfile)\ if os.path.isfile(logfile) and not pUtil.isLogfileCopied(job_state.site.workdir) else "" remaining_files = [] filesDir = '' if os.path.isdir(job_state.job.datadir): pUtil.chdir(job_state.job.datadir) remaining_files = pUtil.getRemainingOutputFiles(job_state.job.outFiles) if not remaining_files: remaining_files = [] filesDir = os.path.abspath(job_state.job.datadir) pUtil.chdir(currentDir) return ReturnCode.OK, logfile, filesDir, remaining_files
def getXML(self, job, sitename, workdir, xmlstr=None, jr=False): """ Get the metadata xml """ node_xml = "" tolog("getXML called") # for backwards compatibility try: experiment = job.experiment except: experiment = "unknown" # do not send xml for state 'holding' (will be sent by a later pilot during job recovery) if job.result[0] == 'holding' and sitename != "CERNVM": pass else: # only create and send log xml if the log was transferred if job.result[0] == 'failed' and isLogfileCopied(workdir): # generate the xml string for log file # at this time the job.workdir might have been removed (because this function can be called # after the removal of workdir is done), so we make a new dir xmldir = "%s/XML4PandaJob_%s" % (workdir, job.jobId) # group rw permission added as requested by LYON ec, rv = getstatusoutput("mkdir -m g+rw %s" % (xmldir)) if ec != 0: tolog("!!WARNING!!1300!! Could not create xmldir from updatePandaServer: %d, %s (resetting to site workdir)" % (ec, rv)) cmd = "ls -l %s" % (xmldir) out = getoutput(cmd) tolog("%s \n%s" % (cmd, out)) xmldir = workdir # which checksum command should be used? query the site mover from SiteMoverFarm import getSiteMover sitemover = getSiteMover(readpar('copytool'), "") if os.environ.has_key('Nordugrid_pilot'): fname = os.path.join(self.__pilot_initdir, job.logFile) else: fname = os.path.join(workdir, job.logFile) if os.path.exists(fname): fnamelog = "%s/logfile.xml" % (xmldir) guids_status = PFCxml(experiment, fnamelog, fntag="lfn", alog=job.logFile, alogguid=job.tarFileGuid, jr=jr) from SiteMover import SiteMover ec, pilotErrorDiag, _fsize, _checksum = SiteMover.getLocalFileInfo(fname, csumtype=sitemover.getChecksumCommand()) if ec != 0: tolog("!!WARNING!!1300!! getLocalFileInfo failed: (%d, %s, %s)" % (ec, str(_fsize), str(_checksum))) tolog("!!WARNING!!1300!! Can not set XML (will not be sent to server)") node_xml = '' else: ec, _strXML = updateMetadata(fnamelog, _fsize, _checksum) if ec == 0: tolog("Added (%s, %s) to metadata file (%s)" % (_fsize, _checksum, fnamelog)) else: tolog("!!WARNING!!1300!! Could not add (%s, %s) to metadata file (%s). XML will be incomplete: %d" %\ (_fsize, _checksum, fnamelog, ec)) # add skipped file info _skippedfname = os.path.join(workdir, "skipped.xml") if os.path.exists(_skippedfname): ec = addSkippedToPFC(fnamelog, _skippedfname) try: f = open(fnamelog) except Exception,e: tolog("!!WARNING!!1300!! Exception caught: Can not open the file %s: %s (will not send XML)" %\ (fnamelog, str(e))) node_xml = '' else: node_xml = '' for line in f: node_xml += line f.close() # transfer logfile.xml to pilot init dir for Nordugrid if os.environ.has_key('Nordugrid_pilot'): try: copy2(fnamelog, self.__pilot_initdir) except Exception, e: tolog("!!WARNING!!1600!! Exception caught: Could not copy NG log metadata file to init dir: %s" % str(e)) else: tolog("Successfully copied NG log metadata file to pilot init dir: %s" % (self.__pilot_initdir))
node_xml = '' for line in f: node_xml += line f.close() # transfer logfile.xml to pilot init dir for Nordugrid if os.environ.has_key('Nordugrid_pilot'): try: copy2(fnamelog, self.__pilot_initdir) except Exception, e: tolog("!!WARNING!!1600!! Exception caught: Could not copy NG log metadata file to init dir: %s" % str(e)) else: tolog("Successfully copied NG log metadata file to pilot init dir: %s" % (self.__pilot_initdir)) else: # log file does not exist anymore if isLogfileCopied(workdir): tolog("Log file has already been copied and removed") if not os.environ.has_key('Nordugrid_pilot'): # only send xml with log info if the log has been transferred if xmlstr: node_xml = xmlstr tolog("Found xml anyway (stored since before)") else: node_xml = '' tolog("!!WARNING!!1300!! XML not found, nothing to send to server") else: tolog("!!WARNING!!1300!! File %s does not exist and transfer lockfile not found (job from old pilot?)" % (fname)) node_xml = '' elif xmlstr: # xmlstr was set in postJobTask for all files
def DeferredStageoutJob(job_dir, job_state_file="", deferred_stageout_logfile=False, **kwargs): """ Performs stageing out preparation and stages out the job in specified directory. :param job_dir: (string) directory with a job. mandatory parameter :param job_state_file: (string) path to job state file or other file containing job state. If empty, job state file is located as job_dir+'/jobState-*.*'. defaults to "" :param deferred_stageout_logfile: (string|False) template name for deferred log stageout Replaces "{job_id}" with current job id like "log-{job_id}.txt" -> "log-124124.txt" Default False Other parameters are passed into other functions :return: (bool) the fact of stageout being performed """ log('Deferred stageout from job directory "%s"' % job_dir) job_state = JobState() if job_state_file == "": try: job_state_file = glob(job_dir + "/" + jobState_file_wildcart)[0] except: log("There is no job state file in the provided directory, exiting") return False log("Job state file is %s" % job_state_file) # lockfd, lockfn = createAtomicLockFile(job_dir) with LockFileWrapper(job_dir): if not TestJobDirForDeferredStageoutNecessity(job_dir, job_state_file, **kwargs): log('Job "%s" does not need deferred stageout procedure (yet)' % job_dir) # releaseAtomicLockFile(lockfd, lockfn) return False if not job_state.get(job_state_file): log("Job state file reading failed, exiting") # releaseAtomicLockFile(lockfd, lockfn) return False log('Working with job in "%s"' % job_dir) _job, _site, _node, _recoveryAttempt = job_state.decode() if not (_job and _site and _node): log("Can not decode jobState file, exiting") # releaseAtomicLockFile(lockfd, lockfn) return False with LogWrapper(deferred_stageout_logfile, _job.jobId) as logger: rc = PrepareJobForDeferredStageout(job_state, **kwargs) if rc == ReturnCode.PostJobOnly: pUtil.postJobTask( job_state.job, job_state.site, DorE(kwargs, "workerNode"), DorE(kwargs, "experiment"), jr=True, ra=job_state.recoveryAttempt, ) # releaseAtomicLockFile(lockfd, lockfn) return True if rc > 0: log("Job is not prepared for stageout, exiting") if rc == ReturnCode.Cleanup: cleanup(job_state) # releaseAtomicLockFile(lockfd, lockfn) return False rc, logfile, datadir, filelist = CreateTransferFileList(job_state, **kwargs) XMLStr = "" if datadir == "": try: XMLStr = job_state.node["xml"] except: pass if XMLStr == "": XMLStr = pUtil.getMetadata(job_state.site.workdir, job_state.job.jobId) currentdir = os.getcwd() pUtil.chdir(job_state.site.workdir) if len(filelist): log("Stageout will now transfer the files") rc = TransferFiles(job_state, datadir, filelist, **kwargs) if rc == ReturnCode.Holding: job_state.job.result[0] = "holding" if rc == ReturnCode.FailedJob: job_state.job.result[0] = "failed" job_state.job.setState(job_state.job.result) pUtil.chdir(job_state.site.workdir) ret = True if logfile != "" and not pUtil.isLogfileCopied(job_state.site.workdir): log("Stageout will now transfer the log") _log = JobLog() ret, _ = _log.transferLogFile( job_state.job, job_state.site, DorE(kwargs, "experiment"), dest=None, jr=True ) if not ret: rc = ReturnCode.Holding # We need to transfer log file regardless the files if rc == ReturnCode.OK: if pUtil.verifyTransfer(job_state.site.workdir): job_state.job.result[0] = "finished" else: job_state.job.result[0] = "failed" job_state.job.setState(job_state.job.result) if job_state.job.result[0] in finalJobStates: job_state.job.final_state = job_state.job.result[0] log("Stageout will now update the server with new status") rt, retNode = updatePandaServer(job_state, xmlstr=XMLStr, **kwargs) if rt == 0: log("Job %s updated (exit code %d)" % (job_state.job.jobId, job_state.job.result[2])) # did the server send back a command? if "tobekilled" in job_state.job.action: log("!!WARNING!!1120!! Panda server returned a 'tobekilled' command") job_state.job.result[0] = "failed" # further recovery attempt unnecessary, but keep the work dir for debugging if job_state.job.result[0] == "failed": log("Further recovery attempts will be prevented for failed job (will leave work dir)") if not job_state.rename(job_state.site, job_state.job): log("(Fate of job state file left for next pilot)") else: log("!!WARNING!!1120!! Panda server returned a %d" % (rt)) # store the final state so that the next pilot will know # store the metadata xml retNode["xml"] = XMLStr # update the job state file with the new state information _retjs = pUtil.updateJobState(job_state.job, job_state.site, retNode, job_state.recoveryAttempt) log("Stageout will now proceed to post-job actions") if job_state.job.result[0] in finalJobStates: pUtil.postJobTask( job_state.job, job_state.site, DorE(kwargs, "workerNode"), DorE(kwargs, "experiment"), jr=True, ra=job_state.recoveryAttempt, ) pUtil.chdir(currentdir) # releaseAtomicLockFile(lockfd, lockfn) if job_state.job.result[0] == "finished": log("Stageout will now remove the job, it is in finished state and can be removed") cleanup(job_state) return True
node_xml = '' for line in f: node_xml += line f.close() # transfer logfile.xml to pilot init dir for Nordugrid if os.environ.has_key('Nordugrid_pilot'): try: copy2(fnamelog, self.__pilot_initdir) except Exception, e: tolog("!!WARNING!!1600!! Exception caught: Could not copy NG log metadata file to init dir: %s" % str(e)) else: tolog("Successfully copied NG log metadata file to pilot init dir: %s" % (self.__pilot_initdir)) else: # log file does not exist anymore if isLogfileCopied(workdir, job.jobId): tolog("Log file has already been copied and removed") if not os.environ.has_key('Nordugrid_pilot'): # only send xml with log info if the log has been transferred if xmlstr: node_xml = xmlstr tolog("Found xml anyway (stored since before)") else: node_xml = '' tolog("!!WARNING!!1300!! XML not found, nothing to send to server") else: tolog("!!WARNING!!1300!! File %s does not exist and transfer lockfile not found (job from old pilot?)" % (fname)) node_xml = '' elif xmlstr: # xmlstr was set in postJobTask for all files
def DeferredStageoutJob(job_dir, job_state_file="", deferred_stageout_logfile=False, **kwargs): """ Performs stageing out preparation and stages out the job in specified directory. :param job_dir: (string) directory with a job. mandatory parameter :param job_state_file: (string) path to job state file or other file containing job state. If empty, job state file is located as job_dir+'/jobState-*.*'. defaults to "" :param deferred_stageout_logfile: (string|False) template name for deferred log stageout Replaces "{job_id}" with current job id like "log-{job_id}.txt" -> "log-124124.txt" Default False Other parameters are passed into other functions :return: (bool) the fact of stageout being performed """ log("Deferred stageout from job directory \"%s\"" % job_dir) job_state = JobState() if job_state_file == "": try: job_state_file = glob(job_dir + "/" + jobState_file_wildcart)[0] except: log("There is no job state file in the provided directory, exiting") return False log("Job state file is %s"%job_state_file) # lockfd, lockfn = createAtomicLockFile(job_dir) with LockFileWrapper(job_dir): if not TestJobDirForDeferredStageoutNecessity(job_dir, job_state_file, **kwargs): log("Job \"%s\" does not need deferred stageout procedure (yet)" % job_dir) # releaseAtomicLockFile(lockfd, lockfn) return False if not job_state.get(job_state_file): log("Job state file reading failed, exiting") # releaseAtomicLockFile(lockfd, lockfn) return False log("Working with job in \"%s\"" % job_dir) _job, _site, _node, _recoveryAttempt = job_state.decode() if not (_job and _site and _node): log("Can not decode jobState file, exiting") # releaseAtomicLockFile(lockfd, lockfn) return False with LogWrapper(deferred_stageout_logfile, _job.jobId) as logger: rc = PrepareJobForDeferredStageout(job_state, **kwargs) if rc == ReturnCode.PostJobOnly: pUtil.postJobTask(job_state.job, job_state.site, DorE(kwargs, 'workerNode'), DorE(kwargs, 'experiment'), jr=True, ra=job_state.recoveryAttempt) # releaseAtomicLockFile(lockfd, lockfn) return True if rc > 0: log("Job is not prepared for stageout, exiting") if rc == ReturnCode.Cleanup: cleanup(job_state) # releaseAtomicLockFile(lockfd, lockfn) return False rc, logfile, datadir, filelist = CreateTransferFileList(job_state, **kwargs) XMLStr = '' if datadir == "": try: XMLStr = job_state.node['xml'] except: pass if XMLStr == '': XMLStr = pUtil.getMetadata(job_state.site.workdir, job_state.job.jobId) currentdir = os.getcwd() pUtil.chdir(job_state.site.workdir) if len(filelist): log("Stageout will now transfer the files") rc = TransferFiles(job_state, datadir, filelist, **kwargs) if rc == ReturnCode.Holding: job_state.job.result[0] = "holding" if rc == ReturnCode.FailedJob: job_state.job.result[0] = "failed" job_state.job.setState(job_state.job.result) pUtil.chdir(job_state.site.workdir) ret = True if logfile != "" and not pUtil.isLogfileCopied(job_state.site.workdir): log("Stageout will now transfer the log") _log = JobLog() ret, _ = _log.transferLogFile(job_state.job, job_state.site, DorE(kwargs, 'experiment'), dest=None, jr=True) if not ret: rc = ReturnCode.Holding # We need to transfer log file regardless the files if rc == ReturnCode.OK: if pUtil.verifyTransfer(job_state.site.workdir): job_state.job.result[0] = "finished" else: job_state.job.result[0] = "failed" job_state.job.setState(job_state.job.result) if job_state.job.result[0] in finalJobStates: job_state.job.final_state = job_state.job.result[0] log("Stageout will now update the server with new status") rt, retNode = updatePandaServer(job_state, xmlstr=XMLStr, **kwargs) if rt == 0: log("Job %s updated (exit code %d)" % (job_state.job.jobId, job_state.job.result[2])) # did the server send back a command? if "tobekilled" in job_state.job.action: log("!!WARNING!!1120!! Panda server returned a \'tobekilled\' command") job_state.job.result[0] = "failed" # further recovery attempt unnecessary, but keep the work dir for debugging if job_state.job.result[0] == "failed": log("Further recovery attempts will be prevented for failed job (will leave work dir)") if not job_state.rename(job_state.site, job_state.job): log("(Fate of job state file left for next pilot)") else: log("!!WARNING!!1120!! Panda server returned a %d" % (rt)) # store the final state so that the next pilot will know # store the metadata xml retNode['xml'] = XMLStr # update the job state file with the new state information _retjs = pUtil.updateJobState(job_state.job, job_state.site, retNode, job_state.recoveryAttempt) log("Stageout will now proceed to post-job actions") if job_state.job.result[0] in finalJobStates: pUtil.postJobTask(job_state.job, job_state.site, DorE(kwargs, 'workerNode'), DorE(kwargs, 'experiment'), jr=True, ra=job_state.recoveryAttempt) pUtil.chdir(currentdir) # releaseAtomicLockFile(lockfd, lockfn) if job_state.job.result[0] == "finished": log("Stageout will now remove the job, it is in finished state and can be removed") cleanup(job_state) return True
def updatePandaServer(self, job, site, workerNode, port, xmlstr=None, spaceReport=False, log=None, ra=0, jr=False, useCoPilot=False, stdout_tail="", additionalMetadata=None): """ Update the job status with the jobdispatcher web server. State is a tuple of (jobId, ["jobstatus", transExitCode, pilotErrorCode], timestamp) log = log extracts xmlstr is set in postJobTask for finished jobs (all files). Failed jobs will only send xml for log (created in this function) jr = job recovery mode """ tolog("Updating job status in updatePandaServer(): PandaId=%d, result=%s, time=%s" % (job.getState())) # set any holding job to failed for sites that do not use job recovery (e.g. sites with LSF, that immediately # removes any work directory after the LSF job finishes which of course makes job recovery impossible) if not self.__jobrec: if job.result[0] == 'holding' and site.sitename != "CERNVM": job.result[0] = 'failed' tolog("This site does not support job recovery: HOLDING state reset to FAILED") # note: any changed job state above will be lost for fake server updates, does it matter? # get the node structure expected by the server node = self.getNodeStructure(job, site, workerNode, spaceReport=spaceReport, log=log) # skip the server update (e.g. on NG) if not self.__updateServer: tolog("(fake server update)") return 0, node # get the xml node['xml'] = self.getXML(job, site.sitename, site.workdir, xmlstr=xmlstr, jr=jr) # stdout tail in case job.debug == 'true' if job.debug.lower() == "true" and stdout_tail != "": # protection for potentially large tails stdout_tail = stdout_tail[-2048:] node['stdout'] = stdout_tail tolog("Will send stdout tail:\n%s (length = %d)" % (stdout_tail, len(stdout_tail))) else: if job.debug.lower() != "true": tolog("Stdout tail will not be sent (debug=False)") elif stdout_tail == "": tolog("Stdout tail will not be sent (no stdout tail)") else: tolog("Stdout tail will not be sent (debug=%s, stdout_tail=\'%s\')" % (str(job.debug), stdout_tail)) # PN fake lostheartbeat # if job.result[0] == "finished": # node['state'] = "holding" # node['xml'] = "" # read back node['xml'] from jobState file for CERNVM sendXML = True if site.sitename == "CERNVM": _node = self.getNodeStructureFromFile(site.workdir, repr(job.jobId)) if _node: if _node.has_key('xml'): if _node['xml'] != "": node['xml'] = _node['xml'] tolog("Read back metadata xml from job state file (length: %d)" % len(node['xml'])) else: tolog("No metadata xml present in current job state file (1 - pilot should not send xml at this time)") sendXML = False else: tolog("No xml key in node structure") sendXML = False else: tolog("No metadata xml present in current job state file (2 - pilot should not send xml at this time)") sendXML = False # change the state to holding for initial CERNVM job if not sendXML and (job.result[0] == "finished" or job.result[0] == "failed"): # only set the holding state if the Co-Pilot is used if useCoPilot: job.result[0] = "holding" node['state'] = "holding" # update job state file _retjs = updateJobState(job, site, node, recoveryAttempt=ra) # is it the final update? if job.result[0] == 'finished' or job.result[0] == 'failed' or job.result[0] == 'holding': final = True else: final = False # send the original xml if it exists (end of production job) filenameAthenaXML = "%s/metadata-%s.xml.ATHENA" % (site.workdir, repr(job.jobId)) athenaXMLProblem = False if os.path.exists(filenameAthenaXML) and final: # get the metadata AthenaXML = getMetadata(site.workdir, job.jobId, athena=True) # add the metadata to the node if AthenaXML != "" and AthenaXML != None: tolog("Adding Athena metadata of size %d to node dictionary:\n%s" % (len(AthenaXML), AthenaXML)) node['metaData'] = AthenaXML else: pilotErrorDiag = "Empty Athena metadata in file: %s" % (filenameAthenaXML) athenaXMLProblem = True else: # athena XML should exist at the end of the job if job.result[0] == 'finished' and 'Install' not in site.sitename and 'ANALY' not in site.sitename and 'DDM' not in site.sitename and 'test' not in site.sitename: pilotErrorDiag = "Metadata does not exist: %s" % (filenameAthenaXML) athenaXMLProblem = True # fail the job if there was a problem with the athena metadata # remove the comments below if a certain trf and release should be excluded from sending metadata # trf_exclusions = ['merge_trf.py'] # release_exclusions = ['14.5.2.4'] # jobAtlasRelease = getAtlasRelease(job.atlasRelease) # if athenaXMLProblem and job.trf.split(",")[-1] not in trf_exclusions and jobAtlasRelease[-1] not in release_exclusions: if athenaXMLProblem: tolog("!!FAILED!!1300!! %s" % (pilotErrorDiag)) job.result[0] = "failed" job.result[2] = self.__error.ERR_NOATHENAMETADATA if node.has_key('pilotLog'): node['pilotLog'] += "!!FAILED!!1300!! %s" % (pilotErrorDiag) else: node['pilotLog'] = "!!FAILED!!1300!! %s" % (pilotErrorDiag) node['pilotErrorCode'] = job.result[2] node['state'] = job.result[0] # for backward compatibility try: experiment = job.experiment except: experiment = "unknown" # do not make the update if Nordugrid (leave for ARC to do) if readpar('region') == 'Nordugrid': if final: # update xml with SURLs stored in special SURL dictionary file if self.updateOutputFilesXMLWithSURLs4NG(experiment, site.workdir, job.jobId, job.outputFilesXML): tolog("Successfully added SURLs to %s" % (job.outputFilesXML)) # update xml with SURLs stored in special SURL dictionary file if node.has_key('xml'): tolog("Updating node structure XML with SURLs") node['xml'] = updateXMLWithSURLs(experiment, node['xml'], site.workdir, job.jobId, self.__jobrec) # do not use format 'NG' here else: tolog("WARNING: Found no xml entry in the node structure") # store final node structure in pilot_initdir (will be sent to server by ARC control tower) self.copyNodeStruct4NG(node) tolog("Leaving the final update for the control tower") return 0, node # do not send xml if there was a put error during the log transfer _xml = None if final and node.has_key('xml'): # update xml with SURLs stored in special SURL dictionary file tolog("Updating node structure XML with SURLs") node['xml'] = updateXMLWithSURLs(experiment, node['xml'], site.workdir, job.jobId, self.__jobrec) _xml = node['xml'] if not isLogfileCopied(site.workdir): tolog("Pilot will not send xml about output files since log was not transferred") node['xml'] = "" # should XML be sent at this time? if not sendXML: tolog("Metadata xml will not be sent") if node.has_key('xml'): if node['xml'] != "": _xml = node['xml'] node['xml'] = "" # add experiment specific metadata if final and additionalMetadata != None: tolog("Adding additionalMetadata to node") if 'metaData' in node: node['metaData'] += additionalMetadata else: node['metaData'] = additionalMetadata # make the actual update, repeatedly if necessary (for the final update) ret = makeHTTPUpdate(job.result[0], node, port, url=self.__pshttpurl, path=self.__pilot_initdir) if not ret[2]: # data is None for a failed update attempt tolog("makeHTTPUpdate returned: %s" % str(ret)) return 1, None tolog("ret = %s" % str(ret)) data = ret[1] tolog("data = %s" % str(data)) if data.has_key("command"): job.action = data['command'] try: awk = data['StatusCode'] except: tolog("!!WARNING!!1300!! Having problem updating job status, set the awk to 1 for now, and continue...") awk = "1" else: tolog("jobDispatcher acknowledged with %s" % (awk)) # need to have a return code so subprocess knows if update goes ok or not ecode = int(awk) # use the awk code from jobdispatcher as the exit code # PN fake lostheartbeat # if job.result[0] == "finished": # ecode = 1 # reset xml in case it was overwritten above for failed log transfers if final and node.has_key('xml'): node['xml'] = _xml return ecode, node # ecode=0 : update OK, otherwise something wrong
node_xml = '' for line in f: node_xml += line f.close() # transfer logfile.xml to pilot init dir for Nordugrid if readpar('region') == 'Nordugrid': try: copy2(fnamelog, self.__pilot_initdir) except Exception, e: tolog("!!WARNING!!1600!! Exception caught: Could not copy NG log metadata file to init dir: %s" % str(e)) else: tolog("Successfully copied NG log metadata file to pilot init dir: %s" % (self.__pilot_initdir)) else: # log file does not exist anymore if isLogfileCopied(workdir): tolog("Log file has already been copied and removed") if readpar('region') != 'Nordugrid': # only send xml with log info if the log has been transferred if xmlstr: node_xml = xmlstr tolog("Found xml anyway (stored since before)") else: node_xml = '' tolog("!!WARNING!!1300!! XML not found, nothing to send to server") else: tolog("!!WARNING!!1300!! File %s does not exist and transfer lockfile not found (job from old pilot?)" % (fname)) node_xml = '' elif xmlstr: # xmlstr was set in postJobTask for all files