CMS 3D CMS Logo

Classes | Functions | Variables
submitPVValidationJobs Namespace Reference

Classes

class  BetterConfigParser
 — Classes —############################ More...
 
class  Job
 
class  RefitType
 

Functions

def __del__ (self)
 
def __init__ (self, dataset, job_number, job_id, job_name, isDA, isMC, applyBOWS, applyEXTRACOND, extraconditions, runboundary, lumilist, intlumi, maxevents, gt, allFromGT, alignmentDB, alignmentTAG, apeDB, apeTAG, bowDB, bowTAG, vertextype, tracktype, refittertype, ttrhtype, applyruncontrol, ptcut, CMSSW_dir, the_dir)
 
def as_dict (config)
 
def check_proxy ()
 
def ConfigSectionMap (config, section)
 
def createTheBashFile (self, isUnitTest)
 
def createTheCfgFile (self, lfn)
 
def createTheLSFFile (self)
 
def forward_proxy (rundir)
 
def getBatchjobId (self)
 
def getCommandOutput (command)
 
def getFilesForRun (blob)
 
def getLuminosity (homedir, minRun, maxRun, isRunBased, verbose)
 
def getNEvents (run, dataset)
 
def getOutputBaseName (self)
 
def getOutputBaseNameWithData (self)
 
def getOutputFileName (self)
 
def isInJSON (run, jsonfile)
 
def main ()
 
def mkdir_eos (out_path)
 method to create recursively directories on EOS ############# More...
 
def setEOSout (self, theEOSdir)
 
def split (sequence, size)
 
def submit (self)
 
def to_bool (value)
 
def updateDB (run, runInfo)
 
def updateDB2 ()
 
def write_HTCondor_submit_file (path, logs, name, nruns, proxy_path=None)
 

Variables

string __author__ = 'Marco Musich'
 
string __copyright__ = 'Copyright 2020, CERN CMS'
 
list __credits__ = ['Ernesto Migliore', 'Salvatore Di Guida']
 
string __email__ = 'marco.musich@cern.ch'
 
string __license__ = 'Unknown'
 
string __maintainer__ = 'Marco Musich'
 
int __version__ = 1
 
 action
 
 aJob
 
 alignmentDB = []
 
 alignmentTAG = []
 
 allFromGT = []
 
 apeDB = []
 
 apeTAG = []
 
 applyBOWS = []
 
 applyEXTRACOND = []
 
 applyruncontrol = []
 
 args
 
 BASH_dir
 
 batch_job_id
 
list batchJobIds = []
 declare here the list of jobs that should be waited for More...
 
 bowDB = []
 
 bowTAG = []
 
 cfg_dir
 
 child = os.popen(command)
 
 child1 = os.system(submitcommand1)
 
string cmd = 'dasgoclient -limit=0 -query \'run dataset='+opts.data + (' instance='+opts.instance+'\'' if (opts.instance is not None) else '\'')
 
string cmd2 = ' dasgoclient -limit=0 -query \'file run='+blob[0][0]+' dataset='+blob[0][1]+ (' instance='+blob[1]+'\'' if (blob[1] is not None) else '\'')
 
 CMSSW_dir
 
list conditions = []
 
 config = BetterConfigParser()
 
string config_txt = '\n\n' + CopyRights + '\n\n'
 
 ConfigFile = opts.inputconfig
 
string CopyRights = '##################################\n'
 
 count = pool.map(getFilesForRun,zip(mytuple,instances))
 
 data = child.read()
 
string dbName = "runInfo.pkl"
 
 default
 
string desc = """This is a description of %prog."""
 
 dest
 
dictionary dictionary = {}
 
list doRunBased = []
 
 dump
 
 eosdir = os.path.join("/store/group/alca_trackeralign",USER,"test_out",t)
 
 err = child.close()
 
 extraCondVect = []
 
 file = open(template_cfg_file,'r')
 
 file_info = dict(zip(listOfRuns, count))
 
 fout = open(os.path.join(self.cfg_dir,self.outputCfgName),'w')
 
 gt = []
 
 hadd_script_file = os.path.join(scripts_dir,jobName[iConf]+"_"+opts.taskname+".sh")
 
string harvest_conditions = '"' + " && ".join(["ended(" + jobId + ")" for jobId in batchJobIds]) + '"'
 
 help
 
 HOME = os.environ.get('HOME')
 check first there is a valid grid proxy More...
 
dictionary infos = {}
 
 input_CMSSW_BASE = os.environ.get('CMSSW_BASE')
 
def inputDict = as_dict(config)
 
list inputFiles = []
 
list instances = [opts.instance for entry in mytuple]
 
 intlumi
 
 isDA = []
 
 isMC = []
 
 job_id
 
 job_name = self.output_full_name
 
 job_number
 
 job_submit_file = os.path.join(path, "job_"+name+".submit")
 
string job_submit_template
 
list jobName = []
 Initialize all the variables. More...
 
 jsonDATA = json.load(myJSON)
 
string lastJobCommand = "bsub -o harvester"+opts.taskname+".tmp -q 1nh -w "+harvest_conditions+" "+hadd_script_file
 
def lastJobOutput = getCommandOutput(lastJobCommand)
 
 lfn_list
 
 lfn_with_quotes = map(lambda x: "\'"+x+"\'",lfn)
 
 lib_path = os.path.abspath(os.path.join(input_CMSSW_BASE,"src/Alignment/OfflineValidation/test"))
 
def listOfRuns = out.decode().split("\n")
 
 listOfValidations = config.getResultingSection("validations")
 
 local_proxy = subprocess.check_output(["voms-proxy-info", "--path"]).strip()
 
 log_dir = os.path.join(self.the_dir,"log")
 
 LSF_dir
 
 lumilist = []
 
 lumiToCache = line.split(",")[-1].replace("\r", "")
 
 maxevents = []
 
 mergedFile = None
 
dictionary myCachedLumi = {}
 
dictionary mylist = {}
 
def myLumiDB = getLuminosity(HOME,myRuns[0],myRuns[-1],doRunBased,opts.verbose)
 check that the list of runs is not empty More...
 
list myRuns = []
 
list mytuple = []
 
 nEvents = subprocess.check_output(["das_client", "--limit", "0", "--query", "summary run={} dataset={} | grep summary.nevents".format(run, dataset)])
 
 now = datetime.datetime.now()
 
 od = collections.OrderedDict(sorted(file_info.items()))
 
 opts
 
 out
 
 OUTDIR
 
 output = subprocess.check_output([homedir+"/.local/bin/brilcalc", "lumi", "-b", "STABLE BEAMS","-u", "/pb", "--begin", str(minRun),"--end",str(maxRun),"--output-style","csv","-c","web"])
 
 output_BASH_name
 
 output_file_list1 = list()
 
 output_file_list2 = list()
 
 output_full_name
 
 output_LSF_name
 
 output_number_name
 
 outputCfgName
 
 outputList = out.decode().split('\n')
 
 p = Popen(cmd , shell=True, stdout=PIPE, stderr=PIPE)
 
def params = self.extraCondVect[element].split(',')
 
 parser = OptionParser(description=desc,version='%prog version 0.1')
 
 pool = multiprocessing.Pool(processes=20)
 
 ptcut = []
 
 q = Popen(cmd2 , shell=True, stdout=PIPE, stderr=PIPE)
 
 refittertype = []
 
 run = runFromFilename(f)
 
 runboundary = []
 
dictionary runInfo = {}
 
 runToCache = line.split(",")[0].split(":")[0]
 
 s = Popen(cmd , shell=True, stdout=PIPE, stderr=PIPE)
 
string scripts_dir = "scripts"
 print "==========>",conditions More...
 
def splitList = split(mylist,10)
 
list srcFiles = []
 N.B. More...
 
 stderr
 
 stdout
 
string submissionCommand = "condor_submit "+job_submit_file
 
def submissionOutput = getCommandOutput(submissionCommand)
 
string submitcommand1 = "chmod u+x " + os.path.join(self.LSF_dir,self.output_LSF_name)
 
string t = ""
 
 template_cfg_file = os.path.join(self.CMSSW_dir,"src/Alignment/OfflineValidation/test","PVValidation_T_cfg.py")
 
string text
 
string textToWrite = ''
 now for the extra conditions More...
 
 the_dir
 
 theBaseName = None
 
 theBashDir = None
 
def theDataSet = dataset.split("/")[1]+"_"+(dataset.split("/")[2]).split("-")[0]
 
 thejobIndex = None
 
 theLogDir = os.path.join(os.getcwd(),"log")
 create the log directory More...
 
string theLumi = '1'
 
int totalJobs = 0
 
 tracktype = []
 
 ttrhtype = []
 
 USER = os.environ.get('USER')
 
 vertextype = []
 

Detailed Description

Script that submits CMS Tracker Alignment Primary Vertex Validation workflows,
usage:

submitPVValidationJobs.py -j TEST -D /HLTPhysics/Run2016C-TkAlMinBias-07Dec2018-v1/ALCARECO -i testPVValidation_Relvals_DATA.ini -r

Function Documentation

◆ __del__()

def submitPVValidationJobs.__del__ (   self)

Definition at line 418 of file submitPVValidationJobs.py.

References setEOSout().

418  def __del__(self):

◆ __init__()

def submitPVValidationJobs.__init__ (   self,
  dataset,
  job_number,
  job_id,
  job_name,
  isDA,
  isMC,
  applyBOWS,
  applyEXTRACOND,
  extraconditions,
  runboundary,
  lumilist,
  intlumi,
  maxevents,
  gt,
  allFromGT,
  alignmentDB,
  alignmentTAG,
  apeDB,
  apeTAG,
  bowDB,
  bowTAG,
  vertextype,
  tracktype,
  refittertype,
  ttrhtype,
  applyruncontrol,
  ptcut,
  CMSSW_dir,
  the_dir 
)

Definition at line 366 of file submitPVValidationJobs.py.

References split().

Referenced by Types._Untracked.__getattr__(), plotting._calculateRatios(), utils.ask_ok(), command_line.copy_global_tag(), models.generate(), EgammaHLTValidationUtils.getModuleNamesOfPath(), EgammaHLTValidationUtils.getModulesOfSequence(), Utilities.ignoreAllFiltersOnPath(), svgfig.load_stream(), circuitry.plotSequences(), SequenceTypes.TestModuleCommand.testInsertInto(), Mixins.testMixins.testLargeList(), Config.TestModuleCommand.testModifier(), Config.TestModuleCommand.testProcessExtend(), and SequenceTypes.TestModuleCommand.testVisitor().

366  def __init__(self,dataset, job_number, job_id, job_name, isDA, isMC, applyBOWS, applyEXTRACOND, extraconditions, runboundary, lumilist, intlumi, maxevents, gt, allFromGT, alignmentDB, alignmentTAG, apeDB, apeTAG, bowDB, bowTAG, vertextype, tracktype, refittertype, ttrhtype, applyruncontrol, ptcut, CMSSW_dir ,the_dir):
def __init__(self, dataset, job_number, job_id, job_name, isDA, isMC, applyBOWS, applyEXTRACOND, extraconditions, runboundary, lumilist, intlumi, maxevents, gt, allFromGT, alignmentDB, alignmentTAG, apeDB, apeTAG, bowDB, bowTAG, vertextype, tracktype, refittertype, ttrhtype, applyruncontrol, ptcut, CMSSW_dir, the_dir)

◆ as_dict()

def submitPVValidationJobs.as_dict (   config)

Definition at line 195 of file submitPVValidationJobs.py.

195 def as_dict(config):

◆ check_proxy()

def submitPVValidationJobs.check_proxy ( )

Definition at line 48 of file submitPVValidationJobs.py.

Referenced by forward_proxy(), and main().

◆ ConfigSectionMap()

def submitPVValidationJobs.ConfigSectionMap (   config,
  section 
)

Definition at line 316 of file submitPVValidationJobs.py.

References mkdir_eos(), and print().

Referenced by submitPVValidationJobs.BetterConfigParser.getResultingSection().

316 def ConfigSectionMap(config, section):
317  the_dict = {}
318  options = config.options(section)
319  for option in options:
320  try:
321  the_dict[option] = config.get(section, option)
322  if the_dict[option] == -1:
323  DebugPrint("skip: %s" % option)
324  except:
325  print("exception on %s!" % option)
326  the_dict[option] = None
327  return the_dict
328 
def ConfigSectionMap(config, section)
void print(TMatrixD &m, const char *label=nullptr, bool mathematicaFormat=false)
Definition: Utilities.cc:47

◆ createTheBashFile()

def submitPVValidationJobs.createTheBashFile (   self,
  isUnitTest 
)

Definition at line 547 of file submitPVValidationJobs.py.

References getOutputFileName(), and ALPAKA_ACCELERATOR_NAMESPACE::caPixelDoublets.if().

547  def createTheBashFile(self, isUnitTest):
def createTheBashFile(self, isUnitTest)

◆ createTheCfgFile()

def submitPVValidationJobs.createTheCfgFile (   self,
  lfn 
)

Definition at line 434 of file submitPVValidationJobs.py.

Referenced by getOutputBaseNameWithData().

434  def createTheCfgFile(self,lfn):

◆ createTheLSFFile()

def submitPVValidationJobs.createTheLSFFile (   self)

Definition at line 511 of file submitPVValidationJobs.py.

511  def createTheLSFFile(self):

◆ forward_proxy()

def submitPVValidationJobs.forward_proxy (   rundir)

Definition at line 61 of file submitPVValidationJobs.py.

References check_proxy(), and print().

Referenced by main().

61 def forward_proxy(rundir):

◆ getBatchjobId()

def submitPVValidationJobs.getBatchjobId (   self)

Definition at line 601 of file submitPVValidationJobs.py.

References main(), and split().

601  def getBatchjobId(self):

◆ getCommandOutput()

def submitPVValidationJobs.getCommandOutput (   command)

Definition at line 113 of file submitPVValidationJobs.py.

113 def getCommandOutput(command):

◆ getFilesForRun()

def submitPVValidationJobs.getFilesForRun (   blob)

Definition at line 127 of file submitPVValidationJobs.py.

127 def getFilesForRun(blob):

◆ getLuminosity()

def submitPVValidationJobs.getLuminosity (   homedir,
  minRun,
  maxRun,
  isRunBased,
  verbose 
)

Definition at line 145 of file submitPVValidationJobs.py.

145 def getLuminosity(homedir,minRun,maxRun,isRunBased,verbose):
def getLuminosity(homedir, minRun, maxRun, isRunBased, verbose)

◆ getNEvents()

def submitPVValidationJobs.getNEvents (   run,
  dataset 
)

Definition at line 139 of file submitPVValidationJobs.py.

139 def getNEvents(run, dataset):

◆ getOutputBaseName()

def submitPVValidationJobs.getOutputBaseName (   self)

Definition at line 426 of file submitPVValidationJobs.py.

References getOutputBaseNameWithData().

426  def getOutputBaseName(self):

◆ getOutputBaseNameWithData()

def submitPVValidationJobs.getOutputBaseNameWithData (   self)

Definition at line 430 of file submitPVValidationJobs.py.

References createTheCfgFile().

Referenced by getOutputBaseName().

◆ getOutputFileName()

def submitPVValidationJobs.getOutputFileName (   self)

Definition at line 587 of file submitPVValidationJobs.py.

References submit().

Referenced by createTheBashFile().

587  def getOutputFileName(self):

◆ isInJSON()

def submitPVValidationJobs.isInJSON (   run,
  jsonfile 
)

Definition at line 184 of file submitPVValidationJobs.py.

184 def isInJSON(run,jsonfile):

◆ main()

def submitPVValidationJobs.main ( )

Definition at line 606 of file submitPVValidationJobs.py.

References check_proxy(), forward_proxy(), and print().

Referenced by getBatchjobId().

◆ mkdir_eos()

def submitPVValidationJobs.mkdir_eos (   out_path)

method to create recursively directories on EOS #############

Definition at line 330 of file submitPVValidationJobs.py.

References print(), and split().

Referenced by ConfigSectionMap().

330 def mkdir_eos(out_path):
331  print("============== creating",out_path)
332  newpath='/'
333  for dir in out_path.split('/'):
334  newpath=os.path.join(newpath,dir)
335  # do not issue mkdir from very top of the tree
336  if newpath.find('test_out') > 0:
337  #getCommandOutput("eos mkdir"+newpath)
338  command="eos mkdir "+newpath
339  p = subprocess.Popen(command,shell=True, stdout=subprocess.PIPE, stderr=subprocess.PIPE)
340  (out, err) = p.communicate()
341  print("============== created ",out_path)
342  #print(out,err)
343  p.wait()
344 
345  # now check that the directory exists
346  command2="eos ls "+out_path
347  p = subprocess.Popen(command2,shell=True, stdout=subprocess.PIPE, stderr=subprocess.PIPE)
348  (out, err) = p.communicate()
349  p.wait()
350  if p.returncode !=0:
351  print(out)
352 
def mkdir_eos(out_path)
method to create recursively directories on EOS #############
void print(TMatrixD &m, const char *label=nullptr, bool mathematicaFormat=false)
Definition: Utilities.cc:47

◆ setEOSout()

def submitPVValidationJobs.setEOSout (   self,
  theEOSdir 
)

Definition at line 422 of file submitPVValidationJobs.py.

Referenced by __del__().

422  def setEOSout(self,theEOSdir):
def setEOSout(self, theEOSdir)

◆ split()

def submitPVValidationJobs.split (   sequence,
  size 
)

Definition at line 353 of file submitPVValidationJobs.py.

References FastTimerService_cff.range.

Referenced by TH2PolyOfflineMaps.TH2PolyOfflineMaps.__AddNamedBins(), DMRplotter.DMRplotter.__defineObjects__(), DMRplotter.DMRplotter.__defineSingleObjects__(), cond2xml.CondXmlProcessor.__del__(), Mixins._TypedParameterizable.__findDefaultsFor(), edmStreamStallGrapher.StallMonitorParser.__init__(), __init__(), edmTracerCompactLogViewer.TracerCompactFileParser.__init__(), edmModuleAllocMonitorAnalyze.ModuleAllocCompactFileParser.__init__(), GlobalTag.GlobalTag.__or__(), PhaseITreeProducer.ModuleLvlValuesReader.__TraverseDirTree(), TH2PolyOfflineMaps.TH2PolyOfflineMaps.__TraverseDirTree(), validation._copySubDir(), mps_alisetup.SetupAlignment._fetch_datasets(), mps_alisetup.SetupAlignment._fetch_external_datasets(), mps_alisetup.SetupAlignment._fetch_pede_settings(), electrons_cff._get_bitmapVIDForEle_docstring(), tkal_create_file_lists.FileListCreator._get_track_collection(), Types.InputTag._setValues(), Types.ESInputTag._setValues(), Types.LuminosityBlockRange._valueFromString(), Types.EventRange._valueFromString(), pfTools.adaptPVs(), mps_setup_new_align.add_campaign(), ConfigBuilder.ConfigBuilder.addOutput(), ConfigBuilder.ConfigBuilder.addSource(), Primary4DVertexValidation.analyze(), cmsswVersionTools.PickRelValInputFiles.apply(), data_sources.json_list.as_table(), FSQ::BaseHandler.BaseHandler(), autoAlca.buildList(), cmsHarvester.check_globaltag_exists(), SiPixelUtility.checkME(), GlobalTag.checkPrefix(), GlobalTag.GlobalTag.checkPrefix(), makeHippyCampaign.cmsenv(), recoTauConfTools.cmssw_version(), dqm_diff.collect_directory_filenames(), l1tGTAlgoBlockProducer_cff.collectAlgorithmPaths(), compareDQMOutput.compare(), edm::service::SiteLocalConfigService.computeStatisticsDestination(), CondDBESSource.CondDBESSource(), conditionUploadTest.DB.connect(), createPayload.copyToWorkflowdir(), htmlCreator.create(), pdfCreator.create(), EgHLTOfflineClient.createLooseTightTrigEff(), TkModuleGroupSelector.createModuleGroups(), customisers.customiseMerging(), mkLumiAveragedPlots.decodeLine(), edm::releaseversion::DecomposedReleaseVersion.DecomposedReleaseVersion(), DiMuonV.DiMuonV(), DMR.DMR(), TkMap_script_phase1.downloadnlineDQMhisto(), TkMap_script_phase1.downloadOfflineDQMhisto(), TkMap_script_phase1.downloadOfflinePCLhisto(), getInfo.dumpDate(), getInfo.dumpIDs(), getInfo.dumpInfo(), getInfo.dumpSNs(), MagFieldConfig.expandList(), autoNANO.expandNanoMapping(), fileCollector2.filecheck(), fileCollector.filecheck(), ConfigBuilder.filesFromDASQuery(), ConfigBuilder.filesFromList(), EmbeddingHepMCFilter.fill_cut(), EmbeddingHepMCFilter.fill_cuts(), CrabHelper.CrabHelper.fill_options_from_crab_config(), CondDBESSource.fillList(), edm::ModelFilter.filter(), egHLT::trigTools.filterInactiveTightLooseTriggers(), dcsonly_json_2012.findFileInPath(), golden_json_2012.findFileInPath(), golden_json_2015.findFileInPath(), muon_json_2012.findFileInPath(), cmsLHEtoEOSManager.findXrdDir(), relval_machine.fix_run(), ExceptionHandling.format_typename(), getRunInfo.Func_FillInfoDBS(), getRunInfo.Func_FillInfoHlt(), getRunInfo.Func_FillInfoMagnetHistory(), getRunInfo.Func_FillInfoRunRegistry(), getRunInfo.Func_FillInfoRunSummary(), getRunInfo.Func_GetHtmlTags(), getRunInfo.Func_GetHtmlTagValue(), getRunInfo.Func_GetHtmlTagValueAttr(), svgfig.funcRtoC(), GCP(), pkg.AbstractPkg.generate(), util.rrapi.RRApi.get(), rrapi.RRApi.get(), condformats_serialization_generate.get_clang_version(), Mpslibclass.jobdatabase.get_class(), runTauIdMVA.TauIDEmbedder.get_cmssw_version_number(), cmssw_das_client.get_data(), cmssw_cycle_finder.get_include_packages(), python.rootplot.core.get_labels(), beamvalidation.get_lastIOVs(), beamvalidation.get_listoftags(), compareHistograms.get_node_name(), compareHistograms.get_output_filename(), python.rootplot.core.get_plotpath(), beamvalidation.get_plots(), beamvalidation.get_productionFiles(), compareHistograms.get_run_nr(), getBatchjobId(), python.Lumis.getByLabel(), python.Runs.getByLabel(), python.Events.getByLabel(), createIOVlist.getFileInfo(), DeadROC_duringRun.getFileInPath(), PhaseITreeProducer.getFileInPath(), TH2PolyOfflineMaps.getFileInPath(), edmPickEvents.getFileNames(), EgHLTOfflineSource.getHLTFilterNamesUsed(), showPage.getIB(), compare_using_files.getInfoFromFilename(), production_tasks.MonitorJobs.getjobid(), BeamSpotWorkflow.getListOfFilesToProcess(), BeamSpotWorkflow.getListOfRunsAndLumiFromDBS(), mkLumiAveragedPlots.getLumiPerRun(), BeamSpotWorkflow.getNumberOfFilesToProcessForRun(), HGCalTriggerGeometryV9Imp3.getOrderedTriggerCellsFromModule(), getProcessNameFromBranch(), betterConfigParser.BetterConfigParser.getResultingSection(), submitPVValidationJobs.BetterConfigParser.getResultingSection(), HGCalTriggerGeometryV9Imp3.getScintillatoriEtaiPhi(), HGCalTriggerGeometryV9Imp3.getTriggerCellsFromModule(), checkPayloads.getUploadedIOVs(), cms::DDFilteredView.getValuesNS(), SpecificationBuilder_cfi.Specification.groupBy(), edmPickEvents.guessEmail(), esMonitoring.AsyncLineReaderMixin.handle_read(), pat::TriggerObjectStandAlone.hasAnyName(), dataformats.importDF(), dataformats.indent(), QGLikelihoodCalculator.QGLikelihoodCalculator.init(), edm::InputFileCatalog.init(), edm::FileLocator.init_trivialCatalog(), egHLT::MonElemFuncs.initTightLooseDiObjTrigHistsTrigCuts(), egHLT::MonElemFuncs.initTightLooseTrigHists(), egHLT::MonElemFuncs.initTightLooseTrigHistsTrigCuts(), cmsswSequenceInfo.inspectworkflows(), JetHT.JetHT(), TkAlMap.TkAlMap.load_geometry(), GenObject.GenObject.loadConfigFile(), l1t::L1TGlobalUtil.loadPrescalesAndMasks(), CommonMethods.ls(), buildHistoTypes.main(), uploadPayloads.main(), uploader.main(), splitter.main(), o2oRun_SiStripDCS.main(), SiStripDCSPopCon.main(), o2oRun_SiStripDAQ.main(), checkRuns.main(), SiStripDAQPopCon.main(), cmsswFiletrace.main(), python.rootplot.tree2hists.main(), photons_cff.make_bitmapVID_docstring(), directories2html.make_summary_table(), directories2html.make_twiki_table(), cms::DDFilteredView.match(), mergeLHE.DefaultLHEMerger.merge_init_blocks(), cms::DDFilteredView.mergedSpecifics(), mkdir_eos(), python.diffProv.difference.module_diff(), production_tasks.MonitorJobs.monitor(), MTS.MTS(), ValidationMatrix.name2globaltag(), ValidationMatrix.name2run(), ValidationMatrix.name2runskim(), querying.new_connection_dictionary(), python.rootplot.rootmath.operator_func(), TreeCrawler.packageNameFromFilename(), SpecificationBuilder_cfi.parent(), edm::service::SiteLocalConfigService.parse(), iniparser.ConfigData.parseConfig(), lumi::NormDML.parseLumiCorrector(), convertParamsToOnlineFormat.parseOfflineLUTfile(), HipPyOptionParser.HipPyOptionParser.parseOptions(), Page1Parser.Page1Parser.ParseTrigModePage(), pickleFileParser.pathToList(), pfnInPath.pfnInPath(), DTTPGParamsWriter.pharseLine(), python.rootplot.core.prep_first_draw(), MatrixInjector.MatrixInjector.prepare(), MatrixReader.MatrixReader.prepare(), ConfigBuilder.ConfigBuilder.prepare_VALIDATION(), VIDSelectorValidator.VIDSelectorValidator.processEvents(), PV.PV(), TkAlMap.read_TPLfile(), TkAlMapDesign_phase0_cfg.read_TPLfile(), TkAlMapDesign_phase1_cfg.read_TPLfile(), PhaseITreeProducer.ModuleLvlValuesReader.ReadHistograms(), TH2PolyOfflineMaps.TH2PolyOfflineMaps.ReadHistograms(), crabFunctions.CrabTask.readLogArch(), pickleFileParser.readPicFiles(), MP7FileReader.readRows(), heavyIonJetSetup.removeJECsForMC(), heavyIonJetSetup.removeL1FastJetJECs(), dqmservices::DQMFileIterator.reset(), edm::ProductSelectorRules::Rule.Rule(), cmsDriver.run(), runall.testit.run(), postprocessor.PostProcessor.run(), hippyaddtobaddatafiles.runcfg(), SiStripDCSPopCon.runjob(), SiStripDAQPopCon.runjob(), dataformats.search(), duplicateReflexLibrarySearch.searchDuplicatePlugins(), MP7FileReader.searchLinks(), BeamSpotWorkflow.selectFilesToProcess(), helper.set_pede_option(), PFBlockAlgo.setLinkers(), gen::Pythia6Service.setSLHAFromHeader(), JDrawer.SetSplitRatio(), upgradeWorkflowComponents.UpgradeWorkflowPremixProdLike.setup_(), DTCalibrationWorker.DTCalibrationWorker.setup_crab_env(), jetTools.setupJetCorrections(), upgradeWorkflowComponents.UpgradeWorkflowPremix.setupPU_(), MatrixReader.MatrixReader.showRaw(), SiStripDigitizerAlgorithm.SiStripDigitizerAlgorithm(), DAClusterizerInZ_vect.split(), DAClusterizerInZT_vect.split(), deepMETProducer_cff.split_model_path(), split_path(), EgHLTOfflineSummaryClient.splitStringsToPairs_(), SplitV.SplitV(), pfTools.switchToPFJets(), TkModuleGroupSelector.testSplitOption(), Config.TestModuleCommand.testSubProcess(), CommonMethods.timeoutManager(), cms::DDFilteredView.toNodeNames(), coreTools.RunOnData.toolCode(), coreTools.RemoveMCMatching.toolCode(), jetTools.AddJetCollection.toolCode(), jetTools.UpdateJetCollection.toolCode(), svgfig.totrans(), CastorShowerLibraryMaker.update(), esMonitoring.ElasticReport.update_ps_status(), VariablePlotter.VariablePlotter(), VarRangeCut< ObjType >.VarRangeCut(), DAClusterizerInZT_vect.vertices(), DAClusterizerInZ_vect.vertices_in_blocks(), DAClusterizerInZ_vect.vertices_no_blocks(), mps_fire.write_HTCondor_submit_file_mille(), mps_fire.write_HTCondor_submit_file_pede(), and Zmumu.Zmumu().

353 def split(sequence, size):

◆ submit()

def submitPVValidationJobs.submit (   self)

Definition at line 591 of file submitPVValidationJobs.py.

References print().

Referenced by getOutputFileName(), and CrabHelper.CrabHelper.submit_crab_task().

591  def submit(self):

◆ to_bool()

def submitPVValidationJobs.to_bool (   value)

Definition at line 206 of file submitPVValidationJobs.py.

References str, and updateDB2().

206 def to_bool(value):

◆ updateDB()

def submitPVValidationJobs.updateDB (   run,
  runInfo 
)

Definition at line 237 of file submitPVValidationJobs.py.

237 def updateDB(run,runInfo):

◆ updateDB2()

def submitPVValidationJobs.updateDB2 ( )

Definition at line 218 of file submitPVValidationJobs.py.

Referenced by to_bool().

◆ write_HTCondor_submit_file()

def submitPVValidationJobs.write_HTCondor_submit_file (   path,
  logs,
  name,
  nruns,
  proxy_path = None 
)

Definition at line 76 of file submitPVValidationJobs.py.

76 def write_HTCondor_submit_file(path, logs, name, nruns, proxy_path=None):
def write_HTCondor_submit_file(path, logs, name, nruns, proxy_path=None)

Variable Documentation

◆ __author__

string submitPVValidationJobs.__author__ = 'Marco Musich'
private

Definition at line 12 of file submitPVValidationJobs.py.

◆ __copyright__

string submitPVValidationJobs.__copyright__ = 'Copyright 2020, CERN CMS'
private

Definition at line 13 of file submitPVValidationJobs.py.

◆ __credits__

list submitPVValidationJobs.__credits__ = ['Ernesto Migliore', 'Salvatore Di Guida']
private

Definition at line 14 of file submitPVValidationJobs.py.

◆ __email__

string submitPVValidationJobs.__email__ = 'marco.musich@cern.ch'
private

Definition at line 17 of file submitPVValidationJobs.py.

◆ __license__

string submitPVValidationJobs.__license__ = 'Unknown'
private

Definition at line 15 of file submitPVValidationJobs.py.

◆ __maintainer__

string submitPVValidationJobs.__maintainer__ = 'Marco Musich'
private

Definition at line 16 of file submitPVValidationJobs.py.

◆ __version__

int submitPVValidationJobs.__version__ = 1
private

Definition at line 18 of file submitPVValidationJobs.py.

◆ action

submitPVValidationJobs.action

Definition at line 632 of file submitPVValidationJobs.py.

◆ aJob

submitPVValidationJobs.aJob
Initial value:
1 = Job(opts.data,
2  jobN,
3  thejobIndex,
4  jobName[iConf],isDA[iConf],isMC[iConf],
5  applyBOWS[iConf],applyEXTRACOND[iConf],conditions[iConf],
6  myRuns[jobN], lumilist[iConf], theLumi, maxevents[iConf],
7  gt[iConf],allFromGT[iConf],
8  alignmentDB[iConf], alignmentTAG[iConf],
9  apeDB[iConf], apeTAG[iConf],
10  bowDB[iConf], bowTAG[iConf],
11  vertextype[iConf], tracktype[iConf],
12  refittertype[iConf], ttrhtype[iConf],
13  applyruncontrol[iConf],
14  ptcut[iConf],input_CMSSW_BASE,os.getcwd())

Definition at line 1043 of file submitPVValidationJobs.py.

◆ alignmentDB

list submitPVValidationJobs.alignmentDB = []

Definition at line 388 of file submitPVValidationJobs.py.

◆ alignmentTAG

list submitPVValidationJobs.alignmentTAG = []

Definition at line 389 of file submitPVValidationJobs.py.

◆ allFromGT

list submitPVValidationJobs.allFromGT = []

Definition at line 387 of file submitPVValidationJobs.py.

◆ apeDB

list submitPVValidationJobs.apeDB = []

Definition at line 390 of file submitPVValidationJobs.py.

◆ apeTAG

list submitPVValidationJobs.apeTAG = []

Definition at line 391 of file submitPVValidationJobs.py.

◆ applyBOWS

list submitPVValidationJobs.applyBOWS = []

Definition at line 379 of file submitPVValidationJobs.py.

◆ applyEXTRACOND

list submitPVValidationJobs.applyEXTRACOND = []

Definition at line 380 of file submitPVValidationJobs.py.

◆ applyruncontrol

list submitPVValidationJobs.applyruncontrol = []

Definition at line 398 of file submitPVValidationJobs.py.

◆ args

submitPVValidationJobs.args

Definition at line 642 of file submitPVValidationJobs.py.

◆ BASH_dir

submitPVValidationJobs.BASH_dir

Definition at line 412 of file submitPVValidationJobs.py.

◆ batch_job_id

submitPVValidationJobs.batch_job_id

Definition at line 374 of file submitPVValidationJobs.py.

◆ batchJobIds

list submitPVValidationJobs.batchJobIds = []

declare here the list of jobs that should be waited for

Definition at line 981 of file submitPVValidationJobs.py.

◆ bowDB

list submitPVValidationJobs.bowDB = []

Definition at line 392 of file submitPVValidationJobs.py.

◆ bowTAG

list submitPVValidationJobs.bowTAG = []

Definition at line 393 of file submitPVValidationJobs.py.

◆ cfg_dir

submitPVValidationJobs.cfg_dir

Definition at line 407 of file submitPVValidationJobs.py.

◆ child

submitPVValidationJobs.child = os.popen(command)

◆ child1

submitPVValidationJobs.child1 = os.system(submitcommand1)

◆ cmd

string submitPVValidationJobs.cmd = 'dasgoclient -limit=0 -query \'run dataset='+opts.data + (' instance='+opts.instance+'\'' if (opts.instance is not None) else '\'')

Definition at line 831 of file submitPVValidationJobs.py.

◆ cmd2

string submitPVValidationJobs.cmd2 = ' dasgoclient -limit=0 -query \'file run='+blob[0][0]+' dataset='+blob[0][1]+ (' instance='+blob[1]+'\'' if (blob[1] is not None) else '\'')

Definition at line 129 of file submitPVValidationJobs.py.

◆ CMSSW_dir

submitPVValidationJobs.CMSSW_dir

Definition at line 402 of file submitPVValidationJobs.py.

◆ conditions

list submitPVValidationJobs.conditions = []

Definition at line 679 of file submitPVValidationJobs.py.

Referenced by HcalRawToDigiGPU.acquire(), EcalRawToDigiGPU.acquire(), HBHERecHitProducerGPU.acquire(), EcalRecHitProducerGPU.acquire(), SiStripClusterizerFromRawGPU.acquire(), hcaldqm::utilities.adc2fCDBMinusPedestal(), edm::DataMixingHcalDigiWorker.addHcalPileups(), edm::DataMixingHcalDigiWorker.addHcalSignals(), CompareToObjectMapRecord.analyze(), HcalIsoTrackAnalyzer.analyze(), WriteL1TriggerObjectsTxt.analyze(), CastorMonitorModule.analyze(), HcalHBHEMuonAnalyzer.analyze(), CastorPedestalsAnalysis.analyze(), HcalIsoTrkAnalyzer.analyze(), hcaldqm::utilities.aveTSDB(), HcalPulseContainmentManager.beginRun(), HcalPulseShapes.beginRun(), HcalDataFrameFilter_impl.energySum< QIE11DataFrame >(), SiStripClusterizerFromRawGPU.fill(), reco::HcalNoiseInfoProducer.filldigis(), HcalIsoTrkAnalyzer.fillTree(), HcalIsoTrackAnalyzer.gainFactor(), HcalHBHEMuonAnalyzer.gainFactor(), HcalHBHEMuonHighEtaAnalyzer.gainFactor(), AlCaHcalHBHEMuonProducer.gainFactor(), HcalIsoTrkAnalyzer.gainFactor(), HcalLutManager.getCompressionLutXmlFromCoder(), L1GtVhdlWriterCore.getDefValsFromTriggerMenu(), CastorTTRecord.getEnergy_fC(), HcalLutManager.getHEFineGrainLUTs(), HcalLutManager.getMasks(), HcalLutManager.HcalLutManager(), HcalLutManager.init(), HcalTBDigiProducer.initializeEvent(), CastorDigiProducer.initializeEvent(), HcalDigitizer.initializeEvent(), hcaldqm::utilities.loadADC2fCDB(), stripgpu::SiStripRawToClusterGPUKernel.makeAsync(), HcalSimpleReconstructor.process(), L1GtVhdlWriterCore.processAlgorithmMap(), HcalRealisticZS.produce(), CastorSimpleReconstructor.produce(), ZdcSimpleReconstructor.produce(), EcalUncalibRecHitProducerGPU.produce(), RecHitCorrector.produce(), ZdcHitReconstructor.produce(), ZdcHitReconstructor_Run3.produce(), HcalHitReconstructor.produce(), HFPhase1Reconstructor.produce(), DTChamberMasker.produce(), pat::PATTriggerProducer.produce(), AlCaHcalHBHEMuonProducer.produce(), HBHEPhase1Reconstructor.produce(), edm::DataMixingHcalDigiWorker.putHcal(), HcalTriggerPrimitiveAlgo.run(), SiStripClusterizerFromRawGPU.run(), HcalDataFrameFilter.setConditions(), HcalIsoTrkAnalyzer.storeEnergy(), hcaldqm::utilities.sumQDB(), and HcaluLUTTPGCoder.update().

◆ config

submitPVValidationJobs.config = BetterConfigParser()

Definition at line 698 of file submitPVValidationJobs.py.

◆ config_txt

string submitPVValidationJobs.config_txt = '\n\n' + CopyRights + '\n\n'

Definition at line 450 of file submitPVValidationJobs.py.

◆ ConfigFile

submitPVValidationJobs.ConfigFile = opts.inputconfig

Definition at line 691 of file submitPVValidationJobs.py.

◆ CopyRights

string submitPVValidationJobs.CopyRights = '##################################\n'

Definition at line 41 of file submitPVValidationJobs.py.

◆ count

submitPVValidationJobs.count = pool.map(getFilesForRun,zip(mytuple,instances))

Definition at line 862 of file submitPVValidationJobs.py.

◆ data

submitPVValidationJobs.data = child.read()

Definition at line 120 of file submitPVValidationJobs.py.

◆ dbName

string submitPVValidationJobs.dbName = "runInfo.pkl"

Definition at line 220 of file submitPVValidationJobs.py.

◆ default

submitPVValidationJobs.default

Definition at line 632 of file submitPVValidationJobs.py.

◆ desc

string submitPVValidationJobs.desc = """This is a description of %prog."""

Definition at line 630 of file submitPVValidationJobs.py.

◆ dest

submitPVValidationJobs.dest

Definition at line 632 of file submitPVValidationJobs.py.

◆ dictionary

dictionary submitPVValidationJobs.dictionary = {}

Definition at line 197 of file submitPVValidationJobs.py.

◆ doRunBased

list submitPVValidationJobs.doRunBased = []

Definition at line 665 of file submitPVValidationJobs.py.

◆ dump

submitPVValidationJobs.dump

Definition at line 55 of file submitPVValidationJobs.py.

◆ eosdir

submitPVValidationJobs.eosdir = os.path.join("/store/group/alca_trackeralign",USER,"test_out",t)

Definition at line 653 of file submitPVValidationJobs.py.

◆ err

submitPVValidationJobs.err = child.close()

Definition at line 121 of file submitPVValidationJobs.py.

◆ extraCondVect

list submitPVValidationJobs.extraCondVect = []

Definition at line 381 of file submitPVValidationJobs.py.

◆ file

submitPVValidationJobs.file = open(template_cfg_file,'r')

Definition at line 448 of file submitPVValidationJobs.py.

◆ file_info

submitPVValidationJobs.file_info = dict(zip(listOfRuns, count))

Definition at line 863 of file submitPVValidationJobs.py.

◆ fout

submitPVValidationJobs.fout = open(os.path.join(self.cfg_dir,self.outputCfgName),'w')

Definition at line 445 of file submitPVValidationJobs.py.

◆ gt

list submitPVValidationJobs.gt = []

◆ hadd_script_file

submitPVValidationJobs.hadd_script_file = os.path.join(scripts_dir,jobName[iConf]+"_"+opts.taskname+".sh")

Definition at line 927 of file submitPVValidationJobs.py.

◆ harvest_conditions

string submitPVValidationJobs.harvest_conditions = '"' + " && ".join(["ended(" + jobId + ")" for jobId in batchJobIds]) + '"'

Definition at line 1101 of file submitPVValidationJobs.py.

◆ help

submitPVValidationJobs.help

Definition at line 632 of file submitPVValidationJobs.py.

◆ HOME

submitPVValidationJobs.HOME = os.environ.get('HOME')

check first there is a valid grid proxy

check first there is a valid grid proxy

Definition at line 620 of file submitPVValidationJobs.py.

◆ infos

dictionary submitPVValidationJobs.infos = {}

◆ input_CMSSW_BASE

submitPVValidationJobs.input_CMSSW_BASE = os.environ.get('CMSSW_BASE')

Definition at line 623 of file submitPVValidationJobs.py.

◆ inputDict

def submitPVValidationJobs.inputDict = as_dict(config)

Definition at line 702 of file submitPVValidationJobs.py.

◆ inputFiles

list submitPVValidationJobs.inputFiles = []

Definition at line 934 of file submitPVValidationJobs.py.

◆ instances

list submitPVValidationJobs.instances = [opts.instance for entry in mytuple]

◆ intlumi

submitPVValidationJobs.intlumi

◆ isDA

list submitPVValidationJobs.isDA = []

Definition at line 377 of file submitPVValidationJobs.py.

◆ isMC

list submitPVValidationJobs.isMC = []

Definition at line 378 of file submitPVValidationJobs.py.

◆ job_id

submitPVValidationJobs.job_id

Definition at line 373 of file submitPVValidationJobs.py.

◆ job_name

submitPVValidationJobs.job_name = self.output_full_name

Definition at line 375 of file submitPVValidationJobs.py.

◆ job_number

submitPVValidationJobs.job_number

Definition at line 372 of file submitPVValidationJobs.py.

◆ job_submit_file

def submitPVValidationJobs.job_submit_file = os.path.join(path, "job_"+name+".submit")
\
+x509userproxy        = "{proxy:s}"

Definition at line 101 of file submitPVValidationJobs.py.

◆ job_submit_template

string submitPVValidationJobs.job_submit_template
Initial value:
1 = """\
2 universe = vanilla
3 requirements = (OpSysAndVer =?= "AlmaLinux9")
4 executable = {script:s}
5 output = {jobm:s}/{out:s}.out
6 error = {jobm:s}/{out:s}.err
7 log = {jobm:s}/{out:s}.log
8 transfer_output_files = ""
9 +JobFlavour = "{flavour:s}"
10 queue {njobs:s}
11 """
Writes 'job.submit' file in `path`.
Arguments:
- `path`: job directory
- `script`: script to be executed
- `proxy_path`: path to proxy (only used in case of requested proxy forward)

Definition at line 85 of file submitPVValidationJobs.py.

◆ jobName

list submitPVValidationJobs.jobName = []

Initialize all the variables.

in case there exists a specification for the refitter

Definition at line 662 of file submitPVValidationJobs.py.

Referenced by cond::persistency::O2O_RUN::Table.insert().

◆ jsonDATA

submitPVValidationJobs.jsonDATA = json.load(myJSON)

Definition at line 188 of file submitPVValidationJobs.py.

◆ lastJobCommand

string submitPVValidationJobs.lastJobCommand = "bsub -o harvester"+opts.taskname+".tmp -q 1nh -w "+harvest_conditions+" "+hadd_script_file

Definition at line 1103 of file submitPVValidationJobs.py.

◆ lastJobOutput

def submitPVValidationJobs.lastJobOutput = getCommandOutput(lastJobCommand)

Definition at line 1106 of file submitPVValidationJobs.py.

◆ lfn_list

submitPVValidationJobs.lfn_list

Definition at line 416 of file submitPVValidationJobs.py.

◆ lfn_with_quotes

submitPVValidationJobs.lfn_with_quotes = map(lambda x: "\'"+x+"\'",lfn)

Definition at line 475 of file submitPVValidationJobs.py.

◆ lib_path

submitPVValidationJobs.lib_path = os.path.abspath(os.path.join(input_CMSSW_BASE,"src/Alignment/OfflineValidation/test"))

Definition at line 624 of file submitPVValidationJobs.py.

◆ listOfRuns

def submitPVValidationJobs.listOfRuns = out.decode().split("\n")

Definition at line 835 of file submitPVValidationJobs.py.

◆ listOfValidations

submitPVValidationJobs.listOfValidations = config.getResultingSection("validations")

Definition at line 715 of file submitPVValidationJobs.py.

◆ local_proxy

submitPVValidationJobs.local_proxy = subprocess.check_output(["voms-proxy-info", "--path"]).strip()
Forward proxy to location visible from the batch system.
Arguments:
- `rundir`: directory for storing the forwarded proxy

Definition at line 72 of file submitPVValidationJobs.py.

◆ log_dir

submitPVValidationJobs.log_dir = os.path.join(self.the_dir,"log")

Definition at line 524 of file submitPVValidationJobs.py.

◆ LSF_dir

submitPVValidationJobs.LSF_dir

Definition at line 411 of file submitPVValidationJobs.py.

◆ lumilist

list submitPVValidationJobs.lumilist = []

Definition at line 383 of file submitPVValidationJobs.py.

◆ lumiToCache

submitPVValidationJobs.lumiToCache = line.split(",")[-1].replace("\r", "")

Definition at line 174 of file submitPVValidationJobs.py.

◆ maxevents

list submitPVValidationJobs.maxevents = []

Definition at line 385 of file submitPVValidationJobs.py.

◆ mergedFile

string submitPVValidationJobs.mergedFile = None

Definition at line 982 of file submitPVValidationJobs.py.

◆ myCachedLumi

dictionary submitPVValidationJobs.myCachedLumi = {}
Expects something like
+-------+------+--------+--------+-------------------+------------------+
| nfill | nrun | nls    | ncms   | totdelivered(/fb) | totrecorded(/fb) |
+-------+------+--------+--------+-------------------+------------------+
| 73    | 327  | 142418 | 138935 | 19.562            | 18.036           |
+-------+------+--------+--------+-------------------+------------------+
And extracts the total recorded luminosity (/b).

Definition at line 155 of file submitPVValidationJobs.py.

◆ mylist

def submitPVValidationJobs.mylist = {}

Definition at line 826 of file submitPVValidationJobs.py.

◆ myLumiDB

def submitPVValidationJobs.myLumiDB = getLuminosity(HOME,myRuns[0],myRuns[-1],doRunBased,opts.verbose)

check that the list of runs is not empty

Definition at line 912 of file submitPVValidationJobs.py.

◆ myRuns

list submitPVValidationJobs.myRuns = []

Definition at line 825 of file submitPVValidationJobs.py.

◆ mytuple

list submitPVValidationJobs.mytuple = []

Definition at line 840 of file submitPVValidationJobs.py.

◆ nEvents

submitPVValidationJobs.nEvents = subprocess.check_output(["das_client", "--limit", "0", "--query", "summary run={} dataset={} | grep summary.nevents".format(run, dataset)])

Definition at line 141 of file submitPVValidationJobs.py.

◆ now

submitPVValidationJobs.now = datetime.datetime.now()

Definition at line 644 of file submitPVValidationJobs.py.

Referenced by SonicAcquirer< TritonClient, edm::stream::EDProducer< edm::ExternalWork, Capabilities... > >.acquire(), HBHERecHitProducerGPU.acquire(), edm::CountAndLimit.add(), lumi::RevisionDML.addEntry(), lumi::RevisionDML.addRevision(), lumi::RevisionDML.addRunToCurrentHFDataTag(), dqmservices::DQMFileIterator.advanceToLumi(), SonicOneEDAnalyzer< TritonClient, Capabilities... >.analyze(), DQMEventInfo.analyze(), BeamSpotOnlineFromOfflineConverter.analyze(), HGCalMouseBiteTester.analyze(), HcalLuttoDB.beginJob(), RawEventOutputModuleForBU< Consumer >.beginLuminosityBlock(), condbon.cdbon_write(), checkPayloadAge(), OnlineBeamSpotESProducer.checkSingleBS(), XrdAdaptor::RequestManager.checkSources(), XrdAdaptor::RequestManager.checkSourcesImpl(), dqmservices::DQMFileIterator.collect(), OnlineBeamSpotESProducer.compareBS(), XrdAdaptor::RequestManager.compareSources(), DaqFakeReader.DaqFakeReader(), DQMEventInfo.DQMEventInfo(), DQMHarvestingMetadata.DQMHarvestingMetadata(), dqmservices::DQMMonitoringService.DQMMonitoringService(), DTHVStatusHandler.dumpSnapshot(), XrdAdaptor::XrdReadStatistics.elapsedNS(), BeamSpotOnlineRecordsWriter.endJob(), dqmservices::DQMMonitoringService.evLumi(), DaqFakeReader.fillRawData(), DaqFakeReader.fillTCDSFED(), SonicEDFilter< TritonClient, edm::GlobalCache< G >, Capabilities... >.filter(), edm::service::CondorStatusService.firstUpdate(), FakeBeamMonitor.FitAndFill(), BeamMonitor.FitAndFill(), XrdAdaptor::QualityMetricFactory.get(), cond::persistency.get_timestamp(), cond::persistency.get_timestamp_for_filename(), Fit.getFitQuality(), DTHVStatusHandler.getNewObjects(), edm::service.getTime(), XrdAdaptor::RequestManager.handle(), XrdAdaptor::RequestManager::OpenHandler.HandleResponseWithHosts(), HtrXmlPatternWriter.HtrXmlPatternWriter(), cond::persistency.importPayload(), cond::FileBasedEmptySource.initialize(), edm::InputSource.InputSource(), cond::persistency::IOVEditor.insert(), cond::RunInfo_t.isOnGoing(), edm::TimingServiceBase.jobStarted(), edm::service::CondorStatusService.lastUpdate(), LHCInfoPerFillPopConSourceHandler.LHCInfoPerFillPopConSourceHandler(), LHCInfoPerLSPopConSourceHandler.LHCInfoPerLSPopConSourceHandler(), LHCInfoPopConSourceHandler.LHCInfoPopConSourceHandler(), DQMNet.logme(), edm::InputSource.lumiLimitReached(), makeDummyPayload(), FastTimerService::Measurement.measure(), FastTimerService::Measurement.measure_and_accumulate(), FastTimerService::Measurement.measure_and_store(), Fit.multiplyMatrices(), XrdAdaptor::QualityMetricUniqueSource.newSource(), operator<<(), dqmservices::DQMMonitoringService.outputLumiUpdate(), dqmservices::DQMMonitoringService.outputUpdate(), PeriodicAllocMonitor.PeriodicAllocMonitor(), edm::service::StallMonitor.postBeginJob(), ThroughputService.postEvent(), edm::service::StallMonitor.postEvent(), edm::service::StallMonitor.postEventReadFromSource(), edm::service::StallMonitor.postModuleEvent(), edm::service::StallMonitor.postModuleEventAcquire(), edm::service::StallMonitor.postModuleEventPrefetching(), edm::service::StallMonitor.postModuleGlobalTransition(), edm::service::StallMonitor.postModuleStreamTransition(), edm::service::StallMonitor.postSourceEvent(), edm::service::StallMonitor.preEvent(), edm::service::StallMonitor.preEventReadFromSource(), edm::service::StallMonitor.preModuleEvent(), edm::service::StallMonitor.preModuleEventAcquire(), edm::service::StallMonitor.preModuleGlobalTransition(), edm::service::StallMonitor.preModuleStreamTransition(), ThroughputService.preSourceEvent(), edm::service::StallMonitor.preSourceEvent(), sonic_utils.printDebugTime(), SonicEDProducer< TritonClient, edm::GlobalCache< G >, Capabilities... >.produce(), Fit.PropagateErrors(), edm::storage::XrdFile.readv(), FedRawDataInputSource.readWorker(), DAQSource.readWorker(), XrdAdaptor::RequestManager.requestFailure(), dqmservices::DQMFileIterator.reset(), lumi::CMSRunSummaryDummy2DB.retrieveData(), DQMNet.run(), edm::streamer::StreamerOutputMsgBuilders.serializeEvent(), ALIUtils.set_time_now(), XrdAdaptor::Source.setLastDowngrade(), cond::FileBasedEmptySource.setRunAndEventInfo(), edm::service::tracer.setupFile(), edm::service::moduleAlloc.setupFile(), edm::TimeoutPoolOutputModule.shouldWeCloseFile(), trklet::Timer.start(), edm::service::ConcurrentModuleTimer.start(), trklet::Timer.stop(), edm::service::ConcurrentModuleTimer.stop(), edm::streamer::StreamerOutputMsgBuilders.StreamerOutputMsgBuilders(), edm::storage::StorageAccount::Stamp.tick(), dqmservices::DQMMonitoringService.tryUpdate(), edm::service::CondorStatusService.update(), dqmservices::DQMFileIterator.update_state(), SiStripPayloadHandler< SiStripPayload >.updateConfigMap(), edm::service::CondorStatusService.updateImpl(), cond::service::OnlineDBOutputService.writeIOVForNextLumisection(), and BenchmarkGrd.~BenchmarkGrd().

◆ od

submitPVValidationJobs.od = collections.OrderedDict(sorted(file_info.items()))

◆ opts

submitPVValidationJobs.opts

Definition at line 642 of file submitPVValidationJobs.py.

◆ out

submitPVValidationJobs.out

Definition at line 132 of file submitPVValidationJobs.py.

◆ OUTDIR

submitPVValidationJobs.OUTDIR

Definition at line 424 of file submitPVValidationJobs.py.

◆ output

submitPVValidationJobs.output = subprocess.check_output([homedir+"/.local/bin/brilcalc", "lumi", "-b", "STABLE BEAMS","-u", "/pb", "--begin", str(minRun),"--end",str(maxRun),"--output-style","csv","-c","web"])

Definition at line 162 of file submitPVValidationJobs.py.

◆ output_BASH_name

submitPVValidationJobs.output_BASH_name

Definition at line 414 of file submitPVValidationJobs.py.

◆ output_file_list1

submitPVValidationJobs.output_file_list1 = list()

Definition at line 930 of file submitPVValidationJobs.py.

◆ output_file_list2

submitPVValidationJobs.output_file_list2 = list()

Definition at line 931 of file submitPVValidationJobs.py.

◆ output_full_name

submitPVValidationJobs.output_full_name

Definition at line 404 of file submitPVValidationJobs.py.

◆ output_LSF_name

submitPVValidationJobs.output_LSF_name

Definition at line 413 of file submitPVValidationJobs.py.

◆ output_number_name

submitPVValidationJobs.output_number_name

Definition at line 405 of file submitPVValidationJobs.py.

◆ outputCfgName

submitPVValidationJobs.outputCfgName

Definition at line 408 of file submitPVValidationJobs.py.

◆ outputList

submitPVValidationJobs.outputList = out.decode().split('\n')

Definition at line 134 of file submitPVValidationJobs.py.

◆ p

submitPVValidationJobs.p = Popen(cmd , shell=True, stdout=PIPE, stderr=PIPE)

Definition at line 832 of file submitPVValidationJobs.py.

◆ params

def submitPVValidationJobs.params = self.extraCondVect[element].split(',')

Definition at line 483 of file submitPVValidationJobs.py.

Referenced by cond::persistency::RowBuffer< Types... >._set(), cond::persistency::ConditionBuffer< Types... >._set(), cond::persistency::UpdateBuffer._set(), BeamSpotOnlineObjectsImpl.accessParams(), LHCInfoVectorizedFields.accessParams(), LHCInfoImpl.accessParams(), ALPAKA_ACCELERATOR_NAMESPACE::PFClusterSoAProducer.acquire(), MillePedeAlignmentAlgorithm.addGlobalData(), MillePedeAlignmentAlgorithm.addMeasurementData(), DropBoxMetadata.addRecordParameters(), CreateIdealTkAlRecords.alignToGT(), HcalAmplifier.amplify(), FactorizedJetCorrectorDemo.analyze(), ProduceDropBoxMetadata.analyze(), SiPixelHitEfficiencySource.analyze(), SiStripChannelGainFromDBMiscalibrator.analyze(), SiStripNoisesFromDBMiscalibrator.analyze(), BowedSurfaceAlignmentParameters.apply(), TwoBowedSurfacesAlignmentParameters.apply(), CSCAlignmentCorrections.applyAlignment(), ALPAKA_ACCELERATOR_NAMESPACE::PFRecHitProducerKernelConstruct< CAL >.applyCuts(), TKinFitter.applyDeltaA(), TKinFitter.applyDeltaY(), MillePedeAlignmentAlgorithm.areEmptyParams(), BeamSpotFakeConditions.BeamSpotFakeConditions(), HLTExoticaPlotter.bookHist(), HLTHiggsPlotter.bookHist(), HLTMuonPlotter.bookHist(), HLTHiggsSubAnalysis.bookHist(), HLTExoticaSubAnalysis.bookHist(), MTVHistoProducerAlgoForTracker.bookRecoHistos(), MuonGeometryConstantsBuild.build(), HGCalGeometryLoader.build(), HGCalTBGeometryLoader.build(), HGCalGeometryLoader.buildGeom(), HGCalTBGeometryLoader.buildGeom(), DTGeometryBuilderFromDDD.buildGeometry(), DTGeometryParsFromDD.buildGeometry(), PedeSteerer.buildNoHierarchyCollection(), TkPhase2OTMeasurementDet.buildRecHit(), TkPixelMeasurementDet.buildRecHit(), MillePedeAlignmentAlgorithm.buildUserVariables(), BVertexFilterT< VTX >.BVertexFilterT(), BXVectorSimpleFlatTableProducer< T >.BXVectorSimpleFlatTableProducer(), Averages.calc(), TFitParticleCart.calc4Vec(), TFitParticleECart.calc4Vec(), TFitParticleESpher.calc4Vec(), TFitParticleEtEtaPhi.calc4Vec(), TFitParticleEtThetaPhi.calc4Vec(), TFitParticleSpher.calc4Vec(), TFitParticleEMomDev.calc4Vec(), TFitParticleMCCart.calc4Vec(), TFitParticleMCSpher.calc4Vec(), TFitParticleMomDev.calc4Vec(), TFitParticleEScaledMomDev.calc4Vec(), TFitParticleMCPInvSpher.calc4Vec(), TFitParticleMCMomDev.calc4Vec(), HcalHF_S9S1algorithm.CalcEnergyThreshold(), HIPAlignmentAlgorithm.calcParameters(), HcalHF_S9S1algorithm.CalcSlope(), HcalHF_PETalgorithm.CalcThreshold(), PPSDiamondSampicTimingCalibrationPCLHarvester.calibDb(), l1t::Stage2Layer2JetAlgorithmFirmwareImp1.calibrate(), l1t.calibrateAndRankJets(), l1t.calibrateAndRankTaus(), CandMCMatchTableProducer.CandMCMatchTableProducer(), PedeReader.checkAliParams(), PedeSteererWeakModeConstraints.checkSelectionShiftParameter(), G4muDarkBremsstrahlungModel.chi(), ALPAKA_ACCELERATOR_NAMESPACE::PFClusterProducerKernel.cluster(), L1TOccupancyClient.compareWithStrip(), l1ct::PFTkEGAlgoEmulator.compute_sumPt(), SimpleJetCorrector.correctionBin(), l1t::Stage2Layer1FirmwareFactory.create(), l1t::Stage2Layer2FirmwareFactory.create(), SurfaceDeformationFactory.create(), gen::JetMatching.create(), p2eg::GCTcluster_t.createCaloCrystalCluster(), cond::auth::DecodingKey.createFromInputFile(), edm::ServiceRegistry.createServicesFromConfig(), TGeoMgrFromDdd.createShape(), CSCMonitorModule.CSCMonitorModule(), CSCOfflineClient.CSCOfflineClient(), ecaldqm::DBWriterWorker.DBWriterWorker(), HcalTimeSlewSim.delay(), edm::service::MessageServicePSetValidation.disallowedParam(), SiPixelSCurveCalibrationAnalysis.doFits(), DoubleVertexFilter.DoubleVertexFilter(), G4muDarkBremsstrahlungModel.DsigmaDx(), DTTrig.DTTrig(), EcalSCDynamicDPhiParameters.dynamicDPhiParameters(), EcalSelectiveReadoutProducer.EcalSelectiveReadoutProducer(), EcalSelectiveReadoutSuppressor.EcalSelectiveReadoutSuppressor(), EcalSimRawData.EcalSimRawData(), EgammaL1TkIsolation.EgammaL1TkIsolation(), ElectronMatchedCandidateProducer.ElectronMatchedCandidateProducer(), DTVDriftWriter.endJob(), DTVDriftCalibration.endJob(), cond::persistency::BulkDeleter< Types >.erase(), EventTimeDistribution.EventTimeDistribution(), ChannelPattern.Fill(), SiStripCommissioningSource.fillCablingHistos(), cms::PFMETProducer.fillDescriptions(), edm::eventsetup.fillEventSetupProvider(), edm.fillLooper(), VertexFitterResult.fillParameters(), mkfit::MkBuilder.find_tracks_in_layers(), NearbyPixelClustersProducer.findAllNearbyClusters(), SiPixelCalSingleMuonAnalyzer.findClosestCluster(), NearbyPixelClustersAnalyzer.findClosestCluster(), mkfit::MkBuilder.findTracksStandard(), sistrip::LinearFit.fit(), sistrip::MeanAndStdDev.fit(), MuonAlignmentFromReference.fitAndAlign(), TkLasBeamFitter.fitBeam(), PedeSteerer.fixParameters(), cepgen.fromParameterSet(), getCalibrationLabels(), MatcherUsingTracksAlgorithm.getChi2(), BeamSpotOnlineObjectsImpl.getOneParam(), LHCInfoVectorizedFields.getOneParam(), LHCInfoImpl.getOneParam(), AlignPCLThresholdsHGImpl.getParam(), gen::JetMatchingMadgraph.getParameter(), gen::JetMatchingMGFastJet.getParameter(), BeamSpotOnlineObjectsImpl.getParams(), LHCInfoVectorizedFields.getParams(), LHCInfoImpl.getParams(), HGCalTBGeometry.getSummary(), HGCalGeometry.getSummary(), edm::WorkerManager.getWorker(), MillePedeAlignmentAlgorithm.globalDerivativesHierarchy(), GlobalVariablesTableProducer.GlobalVariablesTableProducer(), GsfEleEmHadD1IsoRhoCut.GsfEleEmHadD1IsoRhoCut(), GsfEleTrkPtIsoRhoCut.GsfEleTrkPtIsoRhoCut(), GsfEleValueMapIsoRhoCut.GsfEleValueMapIsoRhoCut(), HBHEStatusBitSetter.HBHEStatusBitSetter(), HcalFiberPattern.HcalFiberPattern(), HtrXmlPatternTool.HtrXmlPatternTool(), reco::MustacheKernel.inDynamicDPhiWindow(), gen::JetMatchingMadgraph.init(), gen::JetMatchingMGFastJet.init(), DeepMETProducer.initializeGlobalCache(), MLPFProducer.initializeGlobalCache(), reco::MustacheKernel.inMustache(), InputGenJetsParticleSelector.InputGenJetsParticleSelector(), cond::persistency::BulkInserter< Types >.insert(), SimpleJetCorrector.invert(), IsolatedTrackCleaner.IsolatedTrackCleaner(), JetConstituentSelector< T, C >.JetConstituentSelector(), JetIDStudiesSelector.JetIDStudiesSelector(), gen::JetMatchingAlpgen.JetMatchingAlpgen(), gen::JetMatchingMadgraph.JetMatchingMadgraph(), gen::JetMatchingMGFastJet.JetMatchingMGFastJet(), JetSignalVertexCompatibility.JetSignalVertexCompatibility(), l1t.JetToGtPtScales(), L1ScalersClient.L1ScalersClient(), L1TStage2uGTTiming.L1TStage2uGTTiming(), btag::LeptonSelector.LeptonSelector(), BTagCalibrationReader::BTagCalibrationReaderImpl.load(), HcalPatternSource.loadPatternFile(), ME0SegAlgoRU.lookForSegments(), GE0SegAlgoRU.lookForSegments(), edm::eventsetup.makeEventSetupProvider(), edm.makeInput(), TkClonerImpl.makeShared(), L1TMuonBarrelKalmanStubProcessor.makeStubs(), MatacqProducer.MatacqProducer(), mkfit::CombCandidate.mergeCandsAndBestShortOne(), MuDigiBaseProducer< DETECTOR_T, DIGI_T >.MuDigiBaseProducer(), MuonDDDConstants.MuonDDDConstants(), PhysicsTools::MVAComputerESSourceBase.MVAComputerESSourceBase(), edm::service::MessageServicePSetValidation.noBadParams(), ALPAKA_ACCELERATOR_NAMESPACE::PFRecHitProducerKernelConstruct< CAL >.operator()(), ThreadSafeFunctor< StringObjectFunction< reco::Photon > >.operator()(), TkClonerImpl.operator()(), BSpdfsFcn.operator()(), operator<<(), EcalMustacheSCParameters.parabolaParameters(), JetResolution.parameterEtaEval(), gen.parseHeader(), cond.parseLineForNamedParams(), PPSTimingCalibrationESSource.parsePPSDiamondJsonFile(), PPSTimingCalibrationESSource.parseTotemUFSDJsonFile(), reco::IPTagInfo< Container, Base >.passVariableJTA(), PedsFullNoiseTask.PedsFullNoiseTask(), PFJetIDSelectionFunctor.PFJetIDSelectionFunctor(), PhoGenericQuadraticRhoPtScaledCut.PhoGenericQuadraticRhoPtScaledCut(), PhoGenericRhoPtScaledCut.PhoGenericRhoPtScaledCut(), EcalSCDynamicDPhiParameters.print(), EcalMustacheSCParameters.print(), HIPAlignmentAlgorithm.processHit1D(), HIPAlignmentAlgorithm.processHit2D(), ALPAKA_ACCELERATOR_NAMESPACE::PFRecHitProducerKernel< CAL >.processRecHits(), pat::LeptonUpdater< T >.produce(), ALPAKA_ACCELERATOR_NAMESPACE::PFClusterSoAProducer.produce(), EcalDigiToRaw.produce(), L1CaloJetProducer.produce(), Phase2L1CaloEGammaEmulator.produce(), CSCOverlapsTrackPreparation.produce(), L1EGCrystalClusterEmulatorProducer.produce(), HcalChannelPropertiesEP.produce1(), HcalChannelPropertiesEP.produce2(), CTPPSTimingTrackRecognition< CTPPSDiamondLocalTrack, CTPPSDiamondRecHit >.producePartialTracks(), SiStripApvSimulationParameters.putTEC(), SiStripApvSimulationParameters.putTIB(), SiStripApvSimulationParameters.putTID(), SiStripApvSimulationParameters.putTOB(), PVObjectSelector.PVObjectSelector(), PVSelector.PVSelector(), Pythia8Hadronizer.Pythia8Hadronizer(), Pythia8HepMC3Hadronizer.Pythia8HepMC3Hadronizer(), CSCChamberFitter.radiusCorrection(), SimpleHBHEPhase1Algo.reconstruct(), ProtonReconstructionAlgorithm.reconstructFromMultiRP(), DBoxMetadataHelper::RecordMetaDataInfo.RecordMetaDataInfo(), l1t.RegionCorrection(), BowedSurfaceAlignmentParameters.rotation(), cond::persistency::RowBuffer< Types... >.RowBuffer(), RPDetDigitizer.RPDetDigitizer(), RPHitChargeConverter.RPHitChargeConverter(), RPixChargeShare.RPixChargeShare(), RPixDetDigitizer.RPixDetDigitizer(), RPixDummyROCSimulator.RPixDummyROCSimulator(), RPixHitChargeConverter.RPixHitChargeConverter(), RPixLinearChargeCollectionDrifter.RPixLinearChargeCollectionDrifter(), RPixLinearChargeDivider.RPixLinearChargeDivider(), RPixPileUpSignals.RPixPileUpSignals(), RPLinearChargeCollectionDrifter.RPLinearChargeCollectionDrifter(), RPLinearChargeDivider.RPLinearChargeDivider(), RPLinearInduceChargeOnStrips.RPLinearInduceChargeOnStrips(), RPPileUpSignals.RPPileUpSignals(), RPSimTopology.RPSimTopology(), RPVFATSimulator.RPVFATSimulator(), L1MuBMSEU.run(), L1MuBMEtaProcessor.run(), RunLumiSelector.RunLumiSelector(), ALPAKA_ACCELERATOR_NAMESPACE::PFClusterProducerKernel.seedTopoAndContract(), PedeSteerer.selectCoordinateAlis(), cond::persistency::RowBuffer< Types... >.set(), cond::persistency::ConditionBuffer< Types... >.set(), cond::persistency::UpdateBuffer.setColumnData(), l1t::CaloParamsHelperO2O.setEgCalibrationParams(), l1t::CaloParamsHelper.setEgCalibrationParams(), l1t::CaloParamsHelperO2O.setEgPUSParams(), l1t::CaloParamsHelper.setEgPUSParams(), l1tp2::CaloJet.setExperimentalParams(), l1tp2::CaloCrystalCluster.setExperimentalParams(), setIf(), l1t::CaloParamsHelperO2O.setJetCalibrationParams(), l1t::CaloParamsHelper.setJetCalibrationParams(), l1t::CaloParamsHelperO2O.setJetPUSParams(), l1t::CaloParamsHelper.setJetPUSParams(), l1t::CaloParamsHelperO2O.setLayer1ECalScaleETBins(), l1t::CaloParamsHelper.setLayer1ECalScaleETBins(), l1t::CaloParamsHelperO2O.setLayer1ECalScaleFactors(), l1t::CaloParamsHelper.setLayer1ECalScaleFactors(), l1t::CaloParamsHelperO2O.setLayer1ECalScalePhiBins(), l1t::CaloParamsHelper.setLayer1ECalScalePhiBins(), l1t::CaloParamsHelperO2O.setLayer1HCalFBLUTLower(), l1t::CaloParamsHelper.setLayer1HCalFBLUTLower(), l1t::CaloParamsHelperO2O.setLayer1HCalFBLUTUpper(), l1t::CaloParamsHelper.setLayer1HCalFBLUTUpper(), l1t::CaloParamsHelperO2O.setLayer1HCalScaleETBins(), l1t::CaloParamsHelper.setLayer1HCalScaleETBins(), l1t::CaloParamsHelperO2O.setLayer1HCalScaleFactors(), l1t::CaloParamsHelper.setLayer1HCalScaleFactors(), l1t::CaloParamsHelperO2O.setLayer1HCalScalePhiBins(), l1t::CaloParamsHelper.setLayer1HCalScalePhiBins(), l1t::CaloParamsHelperO2O.setLayer1HFScaleETBins(), l1t::CaloParamsHelper.setLayer1HFScaleETBins(), l1t::CaloParamsHelperO2O.setLayer1HFScaleFactors(), l1t::CaloParamsHelper.setLayer1HFScaleFactors(), l1t::CaloParamsHelperO2O.setLayer1HFScalePhiBins(), l1t::CaloParamsHelper.setLayer1HFScalePhiBins(), ecaldqm::DQWorker.setME(), BeamSpotOnlineObjectsImpl.setOneParam(), LHCInfoVectorizedFields.setOneParam(), LHCInfoImpl.setOneParam(), AlignPCLThresholdsHGImpl.setParam(), PedeReader.setParameter(), TkFittedLasBeam.setParameters(), ecaldqm::PiZeroTask.setParams(), ecaldqm::GpuTask.setParams(), LHCInfoVectorizedFields.setParams(), BeamSpotOnlineObjectsImpl.setParams(), LHCInfoImpl.setParams(), l1t::CaloParamsHelperO2O.setRegionPUSParams(), l1t::CaloParamsHelper.setRegionPUSParams(), ecaldqm::DQWorkerClient.setSource(), l1t::CaloParamsHelperO2O.setTauCalibrationParams(), l1t::CaloParamsHelper.setTauCalibrationParams(), l1t::CaloParamsHelperO2O.setTauPUSParams(), l1t::CaloParamsHelper.setTauPUSParams(), mkfit::TTreeValidation.setupCMSSWMatching(), SherpaHadronizer.SherpaHadronizer(), SimpleFlatTableProducer< T >.SimpleFlatTableProducer(), SimpleFlatTableProducerBase< T, BXVector< T > >.SimpleFlatTableProducerBase(), SimpleFlatTableProducerBaseLumi< T, T >.SimpleFlatTableProducerBaseLumi(), SimpleFlatTableProducerBaseRun< T, T >.SimpleFlatTableProducerBaseRun(), SimpleTypedExternalFlatTableProducer< T, V >.SimpleTypedExternalFlatTableProducer(), SiStripLorentzAngleRunInfoTableProducer.SiStripLorentzAngleRunInfoTableProducer(), SonicClientBase.SonicClientBase(), l1t::Stage2Layer2JetSumAlgorithmFirmwareImp1.Stage2Layer2JetSumAlgorithmFirmwareImp1(), l1t::Stage2MainProcessorFirmwareImp1.Stage2MainProcessorFirmwareImp1(), l1t::Stage2PreProcessorFirmwareImp1.Stage2PreProcessorFirmwareImp1(), TagInfoMVACategorySelector.TagInfoMVACategorySelector(), l1t.TauToGtPtScales(), TemplatedInclusiveVertexFinder< InputContainer, VTX >.TemplatedInclusiveVertexFinder(), TemplatedSecondaryVertexProducer< IPTI, VTX >.TemplatedSecondaryVertexProducer(), TemplatedVertexArbitrator< InputContainer, VTX >.TemplatedVertexArbitrator(), TemplatedVertexMerger< VTX >.TemplatedVertexMerger(), ME0ReDigiProducer::TemporaryGeometry.TemporaryGeometry(), egPM::TF1Wrap< ParamType, bool >.TF1Wrap(), egPM::TF2Wrap< ParamType, bool >.TF2Wrap(), egPM::TF3Wrap< ParamType, bool >.TF3Wrap(), ThreadSafeFunctor< StringObjectFunction< reco::Photon > >.ThreadSafeFunctor(), CombinedMVAV2JetTagComputer::Tokens.Tokens(), GenericMVAJetTagComputer::Tokens.Tokens(), track_associator.trackAssociationChi2(), reco::TrackSelector.TrackSelector(), TrajectoryStateClosestToPoint.TrajectoryStateClosestToPoint(), BowedSurfaceAlignmentParameters.translation(), TritonClient.TritonClient(), HcalTBSource.unpackSetup(), gen::JetMatchingMadgraph.updateOrDie(), gen::JetMatchingMGFastJet.updateOrDie(), reco::IPTagInfo< Container, Base >.variableJTA(), WPlusJetsEventSelector.WPlusJetsEventSelector(), AlignmentParametersIORoot.writeOne(), WSelector.WSelector(), and L1TOccupancyClient.xySymmetry().

◆ parser

submitPVValidationJobs.parser = OptionParser(description=desc,version='%prog version 0.1')

Definition at line 631 of file submitPVValidationJobs.py.

◆ pool

submitPVValidationJobs.pool = multiprocessing.Pool(processes=20)

Definition at line 861 of file submitPVValidationJobs.py.

◆ ptcut

list submitPVValidationJobs.ptcut = []

◆ q

submitPVValidationJobs.q = Popen(cmd2 , shell=True, stdout=PIPE, stderr=PIPE)

Definition at line 131 of file submitPVValidationJobs.py.

◆ refittertype

list submitPVValidationJobs.refittertype = []

Definition at line 396 of file submitPVValidationJobs.py.

◆ run

submitPVValidationJobs.run = runFromFilename(f)

Definition at line 227 of file submitPVValidationJobs.py.

◆ runboundary

list submitPVValidationJobs.runboundary = []

Definition at line 382 of file submitPVValidationJobs.py.

◆ runInfo

dictionary submitPVValidationJobs.runInfo = {}

◆ runToCache

submitPVValidationJobs.runToCache = line.split(",")[0].split(":")[0]

Definition at line 173 of file submitPVValidationJobs.py.

◆ s

submitPVValidationJobs.s = Popen(cmd , shell=True, stdout=PIPE, stderr=PIPE)

Definition at line 940 of file submitPVValidationJobs.py.

◆ scripts_dir

string submitPVValidationJobs.scripts_dir = "scripts"

print "==========>",conditions

Definition at line 924 of file submitPVValidationJobs.py.

◆ splitList

def submitPVValidationJobs.splitList = split(mylist,10)

Definition at line 946 of file submitPVValidationJobs.py.

Referenced by DTHVStatusHandler.getChannelSplit().

◆ srcFiles

list submitPVValidationJobs.srcFiles = []

N.B.

: this is dediced here once and for all

Definition at line 628 of file submitPVValidationJobs.py.

◆ stderr

submitPVValidationJobs.stderr

Definition at line 55 of file submitPVValidationJobs.py.

◆ stdout

submitPVValidationJobs.stdout
Check if GRID proxy has been initialized.

Definition at line 55 of file submitPVValidationJobs.py.

◆ submissionCommand

string submitPVValidationJobs.submissionCommand = "condor_submit "+job_submit_file

Definition at line 1080 of file submitPVValidationJobs.py.

◆ submissionOutput

def submitPVValidationJobs.submissionOutput = getCommandOutput(submissionCommand)

Definition at line 1081 of file submitPVValidationJobs.py.

◆ submitcommand1

string submitPVValidationJobs.submitcommand1 = "chmod u+x " + os.path.join(self.LSF_dir,self.output_LSF_name)

Definition at line 595 of file submitPVValidationJobs.py.

◆ t

string submitPVValidationJobs.t = ""

Definition at line 649 of file submitPVValidationJobs.py.

Referenced by GPUCACellT< TrackerTraits >.__attribute__(), cms::cuda::HistoContainer< T, NBINS, SIZE, S, I, NHISTS >.__attribute__(), Matriplex.__attribute__(), RunManagerMTWorker.abortEvent(), funct.abs(), Matriplex.abs(), RecoTrackAccumulator.accumulateEvent(), CaloTruthAccumulator.accumulateEvent(), MtdTruthAccumulator.accumulateEvent(), edm::ChildrenCPUTimer.add(), edm::WallclockTimer.add(), edm::CPUTimer.add(), DTVDriftCalibration::cellInfo.add(), reco::fitHelper::Adder< C >.add(), reco::fitHelper::Adder< edm::OwnVector< T > >.add(), reco::fitHelper.add(), reco::GsfElectron.addAmbiguousGsfTrack(), L1TCorrelatorLayer1Producer.addDecodedMuon(), L1TCorrelatorLayer1Producer.addDecodedTrack(), CaloParticle.addG4Track(), SimCluster.addG4Track(), TrackingParticle.addG4Track(), TrajectorySegmentBuilder.addGroup(), fireworks.addRhoZEnergyProjection(), fireworks.addSiStripClusters(), TmpSimEvent.addTrack(), L1TCorrelatorLayer1Producer.addTrack(), DeDxDiscriminatorLearner.algoAnalyzeTheTree(), algorithm(), CkfDebugger.analyseCompatibleMeasurements(), HcalPulseShapes.analyticPulseShapeSiPMHE(), HcalPulseShapes.analyticPulseShapeSiPMHO(), CSCStubEfficiencyValidation.analyze(), CSCStubResolutionValidation.analyze(), TrackingTruthValid.analyze(), myFastSimVal.analyze(), DD4hep_TrackingMaterialAnalyser.analyze(), TrackingMaterialAnalyser.analyze(), DD4hep_ListIds.analyze(), L1Scalers.analyze(), AutocorrelationAnalyzer.analyze(), dEdxAnalyzer.analyze(), WValidation.analyze(), dEdxHitAnalyzer.analyze(), HcalForwardLibWriter.analyze(), DrellYanValidation.analyze(), SiPixelPhase1TrackingParticleV.analyze(), DD4hep_ListGroups.analyze(), BeamMonitor.analyze(), L1TDTTPG.analyze(), ValidationMisalignedTracker.analyze(), TrackParameterAnalyzer.analyze(), L1TFED.analyze(), SagittaBiasNtuplizer.analyze(), SiStripCommissioningSource.analyze(), CaloParticleDebugger.analyze(), edmtest::TableTestAnalyzer.analyze(), BPHMonitor.analyze(), HcalRecHitsAnalyzer.analyze(), HcalRecHitsValidation.analyze(), DiMuonVertexValidation.analyze(), LaserSorter.analyze(), PFAnalysis.analyze(), TrackerRemapper.analyzeGeneric(), edm::WaitingTaskList.announce(), DetGeomDesc.applyAlignment(), CSCOfflineMonitor.applyCSClabels(), FWGeometryTableManagerBase.applyTransparencyFromEditor(), edm::HepMCProduct.applyVtxGen(), trklet::TrackletCalculatorDisplaced.approxproj(), trklet::TrackletCalculatorDisplaced.approxprojdisk(), trklet::TrackletCalculatorDisplaced.approxtracklet(), EZMgrFL< T >.assign(), EZArrayFL< GlobalPoint >.assign(), helper::SimpleJetTrackAssociator.associate(), TrackAssociatorByHitsImpl.associateRecoToSim(), TrackAssociatorByHitsImpl.associateSimToReco(), helper::SimpleJetTrackAssociator.associateTransient(), edm::AssociationVector< KeyRefProd, CVal, KeyRef, SizeType, KeyReferenceHelper >.AssociationVector(), DTDigitizer.asymGausSmear(), HcalPulseShape.at(), HcalShapeIntegrator.at(), CastorPulseShapes::Shape.at(), trklet::TrackletCalculatorBase.barrelSeeding(), edm::soa::Table< edm::soa::col::Pt, edm::soa::col::Eta, edm::soa::col::Phi, edm::soa::col::Vz >.begin(), LumiCalculator.beginRun(), tmtt::TMTrackProducer.beginRun(), HcalRaddamMuon.beginRun(), HcalHBHEMuonAnalyzer.beginRun(), ExternalLHEProducer.beginRunProduce(), cms::cuda::HistoContainer< T, NBINS, SIZE, S, I, NHISTS >.bin(), cms::alpakatools::HistoContainer< T, NBINS, SIZE, S, I, NHISTS >.bin(), HistogramManager.book(), GeneralPurposeVertexAnalyzer.book(), TkAlV0sAnalyzer.book(), GeneralPurposeTrackAnalyzer.book(), DMRChecker.book(), ShortenedTrackValidation.book(), SiStripLorentzAnglePCLMonitor.bookHistograms(), FWPFCandidateWithHitsProxyBuilder.build(), TransientTrackBuilder.build(), TotemTimingRecHitProducerAlgorithm.build(), FWCandidatePtrProxyBuilder.build(), FWSecVertexProxyBuilder.build(), FWSecVertexCandidateProxyBuilder.build(), FWTrackingParticleProxyBuilder.build(), FWPFCandidate3DProxyBuilder.build(), FWCandidateProxyBuilder.build(), FWTrackingParticleProxyBuilderFullFramework.build(), FWPFPatJet3DProxyBuilder< reco::PFJet >.build(), FWVertexCandidateProxyBuilder.build(), FWVertexProxyBuilder.build(), gen::HijingHadronizer.build_hijing_vertex(), gen::Hydjet2Hadronizer.build_hyjet2_vertex(), gen::HydjetHadronizer.build_hyjet_vertex(), TrackerG4SimHitNumberingScheme.buildAll(), ME0GeometryBuilder.buildEtaPartition(), CmsTrackerDetIdBuilder.buildId(), ME0GeometryBuilder.buildLayer(), MTDGeomBuilderFromGeometricTimingDet.buildPixel(), TrackerGeomBuilderFromGeometricDet.buildPixel(), TrackerGeomBuilderFromGeometricDet.buildPixelPhase2(), SiStripDetVOffBuilder.buildPSUdetIdMap(), TrackerGeomBuilderFromGeometricDet.buildSilicon(), SimTauProducer.buildSimTau(), FWTrackProxyBuilderFullFramework.buildTrack(), Averages.calc(), CSCEventData.calcALCTcrc(), l1t::MicroGMTConfiguration.calcGlobalPhi(), tmtt::TrackerModule.calcModuleType(), CSCStripAmpResponse.calculateAmpResponse(), CSCWireElectronicsSim.calculateAmpResponse(), CSCStripElectronicsSim.calculateAmpResponse(), MahiFit.calculateArrivalTime(), JetPlusTrackProducerAA.calculateBGtracksJet(), ZdcSD.calculateCherenkovDeposit(), trklet::TrackDerTable.calculateDerivatives(), CaloCachedShapeIntegrator.CaloCachedShapeIntegrator(), PrimaryVertexAssignment.chargedHadronVertex(), CSCDCCExaminer.check(), FWGeometryTableManager.checkRegionOfInterest(), MixingWorker.checkSignal(), edm::MixingWorker< T >.checkSignal(), G4muDarkBremsstrahlungModel.chi(), riemannFit.circleFit(), ALPAKA_ACCELERATOR_NAMESPACE::riemannFit.circleFit(), className(), TrajectoryCleanerBySharedHits.clean(), mkfit::Event.clean_cms_seedtracks_badlabel(), mkfit::Event.clean_cms_simtracks(), SimTrackManager.cleanTracksWithHistory(), hybridBitonicSortUtils.clear(), DTBtiChip.clear(), edm::AssociationVector< KeyRefProd, CVal, KeyRef, SizeType, KeyReferenceHelper >.clear(), HGCalLayerTilesT< T, WRAPPER >.clear(), l1tpf_calo::GridData< PreCluster >.clear(), edm::CopyPolicy< T >.clone(), edm::ClonePolicy< T >.clone(), LaserSorter.closeOutStream(), CMS_lumi(), FWEveViewManager.colorsChanged(), funct::Sgn< T >.compose(), funct::Abs< T >.compose(), funct::Cos< T >.compose(), funct::Exp< T >.compose(), funct::Log< T >.compose(), funct::Sin< T >.compose(), funct::Sqrt< T >.compose(), funct::Tan< T >.compose(), EMShower.compute(), Level1TriggerRates.computeRates(), L1TriggerRates.computeRunRates(), edm::moduleAlloc::monitor_file_utilities.concatenate(), edm::service::monitor_file_utilities.concatenate(), CondHDF5ESSource.CondHDF5ESSource(), DDCmsMTDConstruction.construct(), aligned_allocator< T, Alignment >.construct(), fwlite::MultiChainEvent.consumes(), QIE8Simulator.controlOutput(), converter::SuperClusterToCandidate.convert(), converter::TrackToCandidate.convert(), converter::StandAloneMuonTrackToCandidate.convert(), Phase2L1GMT::TrackConverter.convertTracks(), funct.cos(), Matriplex.cos(), cms::alpakatools::HistoContainer< T, NBINS, SIZE, S, I, NHISTS >.count(), TkRadialStripTopology.coveredStrips(), CSCStripElectronicsSim.createDigi(), LMFCorrVers.createObject(), LMFSeqVers.createObject(), LMFTrigType.createObject(), LMFPrimVers.createObject(), LMFIOV.createObject(), LMFRunTag.createObject(), dd4hep.createPlacement(), MuonSeedFromRecHits.createSeed(), MuonSeedCreator.createSeed(), CosmicMuonSeedGenerator.createSeed(), cscClassPackerCompare(), cscPackAndUnpack(), reco::parser.cutParser(), tmtt::ChiSquaredFit4.D(), d2str(), edm::service.d2str(), MaterialBudgetData.dataPerStep(), EcalLaserCondTools.dbToAscii(), cms::DDFilteredView.DDFilteredView(), trklet::TrackletCalculatorDisplaced.DDLSeeding(), edm.decode(), DTPosNegType.decode(), DTPosNeg.decode(), edm.decode_deprecated(), HcalTimeSlewSim.delay(), FWLiteESSource.delaySettingRecords(), EMShower.deposit(), InterpolatedPulse< 1500U >.derivative(), trklet::TrackletCalculatorBase.diskSeeding(), IntegralOverPhiFunction.DoEval(), reco::parser::AnyMethodArgumentFixup.doInt(), DDEcalPreshowerAlgo.doLadders(), edm::Worker.doWorkAsync(), HLTGenValSource.dqmBeginRun(), SiStripLorentzAnglePCLHarvester.dqmEndJob(), DTBtiChip.DTBtiChip(), DTConfigTraco.DTConfigTraco(), DTTMax.DTTMax(), trklet::VarBase.dump(), emtf.dump_fw_raw_input(), trklet::VarBase.dump_msg(), TracksterLinksProducer.dumpTrackster(), TrackstersMergeProducer.dumpTrackster(), ticl::PatternRecognitionbyCLUE3D< TILES >.dumpTracksters(), EcalLaserAPDPNRatiosXMLTranslator.dumpXML(), EcalLinearCorrectionsXMLTranslator.dumpXML(), EcalHitMaker.ecalCellLine(), edm.edmModuleTypeEnum(), DependencyGraph.edmModuleTypeEnum(), ticl::PatternRecognitionbyCA< TILES >.emptyTrackstersFromSeedsTRK(), l1t::demo::codecs.encodeTrack(), edm::soa::Table< edm::soa::col::Pt, edm::soa::col::Eta, edm::soa::col::Phi, edm::soa::col::Vz >.end(), edm::TestMixedSource.endJob(), LumiCalculator.endLuminosityBlock(), ExternalLHEProducer.endRun(), PFEnergyCalibration.energyEmHad(), TracksterLinksProducer.energyRegressionAndID(), TrackstersMergeProducer.energyRegressionAndID(), RooCBExGaussShape.evaluate(), AlignmentMonitorGeneric.event(), FWEveViewManager.eventBegin(), FWEveViewManager.eventCenterChanged(), FWEveViewManager.eventEnd(), trklet::TrackletCalculatorDisplaced.exactproj(), trklet::TrackletCalculatorBase.exactproj(), trklet::TrackletCalculatorDisplaced.exactprojdisk(), trklet::TrackletCalculatorBase.exactprojdisk(), trklet::TrackletCalculatorBase.exacttracklet(), trklet::TrackletCalculatorDisplaced.exacttracklet(), trklet::TrackletCalculatorBase.exacttrackletdisk(), trklet::TrackletCalculatorBase.exacttrackletOverlap(), trklet::FitTrack.execute(), HistogramManager.executeExtend(), HistogramManager.executeGroupBy(), HistogramManager.executeHarvesting(), HistogramManager.executePerEventHarvesting(), funct.exp(), mkfit::MkBuilder.export_tracks(), reco::parser.expressionParser(), TFParams.f3deg(), mkfit::mini_propagators.fast_atan2(), mkfit::mini_propagators.fast_tan(), CTPPSFastTrackingProducer.FastReco(), JanAlignmentAlgorithm.feed(), LMFCorrCoefDat.fetchAfter(), EcalCondDBInterface.fetchDCSDataSet(), SimG4HcalValidation.fetchHits(), LMFLmrSubIOV.fetchIdSql(), EcalCondDBInterface.fetchRunIOV(), EventStringOutputFields.fill(), TriggerOutputFields.fill(), AlignmentPayloadInfo< PayloadType >.fill(), HistogramManager.fill(), FBaseSimEvent.fill(), trklet::TrackDer.fill(), cms::alpakatools::HistoContainer< T, NBINS, SIZE, S, I, NHISTS >.fill(), cond::payloadInspector::RunHistoryPlot< PayloadType, std::pair< double, double > >.fill(), mkfit::Shell.FillByLabelMaps_CkfBase(), EcalLaserCondTools.fillDb(), HcalTestHistoClass.fillHits(), PHcalValidInfoLayer.fillHits(), TopDecaySubset.fillListing(), TopInitSubset.fillOutput(), FastTimerServiceClient.fillPathSummaryPlots(), HcalRecHitsValidation.fillRecHitsTmp(), HcalRecHitsAnalyzer.fillRecHitsTmp(), CkfDebugger.fillSeedHist(), trklet::TrackDerTable.fillTable(), MTDGeometry.fillTestMap(), TrackerGeometry.fillTestMap(), TrackstersMergeProducer.fillTile(), PHcalValidInfoJets.fillTProfileJet(), PHcalValidInfoNxN.fillTProfileNxN(), ProtonTaggerFilter.filter(), edm::GeneratorFilter< HAD, DEC >.filter(), RPCRecHitFilter.filter(), edm::HadronizerFilter< HAD, DEC >.filter(), edm::ConcurrentGeneratorFilter< HAD, DEC >.filter(), edm::ConcurrentHadronizerFilter< HAD, DEC >.filter(), PhotonMCTruthFinder.find(), DTCombinatorialExtendedPatternReco.findCompatibleHits(), TopDecaySubset.findDecayingTops(), reco.findMethod(), PlotAlignmentValidation.findmodule(), TopDecaySubset.findPrimalTops(), findRegions(), ticl::TracksterLinkingbySkeletons.findSkeletonNodes(), TopDecaySubset.findTops(), CSCXonStrip_MatchGatti.findXOnStrip(), sistrip::LinearFit.fit(), CosmicMuonSmoother.fit(), sistrip::MeanAndStdDev.fit(), TFParams.fitpj(), CSCFindPeakTime.fivePoleFitCharge(), hgcalsimclustertime::ComputeClusterTime.fixSizeHighestDensity(), l1ct::PFRegion.floatGlbEtaOf(), l1ct::PFRegion.floatGlbPhiOf(), fnc_gaussalpha(), fnc_gaussalpha1alpha2(), edm::ModuleRegistry.forAllModuleHolders(), FakeBeamMonitor.formatFitTime(), BeamMonitor.formatFitTime(), BeamMonitorBx.formatFitTime(), Vx3DHLTAnalyzer.formatTime(), edm::service::ELstatistics.formSummary(), fpeak(), cond::time.from_boost(), EcalLaserCondTools.from_hdf_to_db(), lumi.from_string(), from_string(), cond::time.from_timeval(), FWCollectionSummaryModelCellRenderer.FWCollectionSummaryModelCellRenderer(), FWCollectionSummaryWidget.FWCollectionSummaryWidget(), HepMCValidationHelper.genMet(), edm::helper::CandMasterKeyReference.get(), edm::helper::AssociationIdenticalKeyReference.get(), get_4(), PPSTools.Get_t_and_xi(), AcceptanceTableHelper.GetAcceptance(), edm::service::ThreadSafeLogMessageLoggerScribe.getAparameter(), QIE8Simulator.getCharge(), HcalLaserEventFilter.GetCMSSWVersion(), LMFCorrCoefDat.getCorrections(), TShapeAnalysis.getDateStart(), TShapeAnalysis.getDateStop(), BeamSpotDipServer.getDateTime(), getDateTime(), LMFRunIOV.getDBInsertionTime(), TrackAssociatorByHitsImpl.getDoubleCount(), edm::RootTree.getEntry(), MuonSimHitMatcher.getIdsOfSimTrackShower(), l1t::rctDataBase.GetIndices(), WatcherStreamFileReader.getInputFile(), edm::JobReport::JobReportImpl.getInputFileForToken(), LMFLmrSubIOV.getIOVIDsLaterThan(), LMFDat.getKeyTypes(), EcalLaserDbService.getLaserCorrection(), l1t::rctDataBase.GetLength(), l1t::rctDataBase.GetLink(), fireworks.getLocalTime(), popcon::EcalLaser_weekly_Handler.getNewObjects(), SiStripPulseShape.getNormalizedValue(), l1t::PhysicsToBitConverter.GetObject(), edm::JobReport::JobReportImpl.getOutputFileForToken(), DTBufferTreeTrait< T >.getOutputValue(), DTBufferTreeTrait< std::unique_ptr< T > >.getOutputValue(), LMFLmrSubIOV.getParameters(), l1tVertexFinder.getPrimaryVertex(), EcalEBPhase2TPParamProducer.getPulseSampleSet(), HFShowerLibrary::BranchReader.getRecordNewFormV3(), DataReducer< T >.getReducedDataList(), PerformancePayloadFromBinnedTFormula.getResult(), PerformancePayloadFromTFormula.getResult(), LMFSeqDat.getSequenceStart(), LMFSeqDat.getSequenceStop(), TrackAssociatorByHitsImpl.getShared(), HcalHitMaker.getSubHcalDet(), LMFRunIOV.getSubRunEnd(), LMFRunIOV.getSubRunStart(), HcalSpecialTimes.getTDCTime(), HcalDDDRecConstants.getThickActive(), LMFLmrSubIOV.getTime(), fireworks.getTimeGMT(), LMFLmrSubIOV.getTimes(), MatacqRawEvent.getTimeStamp(), FWPFTrackUtils.getTrack(), CSCAnalogSignal.getValue(), CSCDriftSim.getWireHit(), LowEnergyFastSimParam.GetZ(), gexp(), reco::GhostTrackPrediction.GhostTrackPrediction(), PixelClusterCountsAuditor.globalBeginLuminosityBlock(), FWEveViewManager.globalEnergyScaleChanged(), CachingSeedCleanerBySharedInput.good(), GroupedCkfTrajectoryBuilder.groupedIntermediaryClean(), hash_value(), FWEveViewManager.haveViewForBit(), HcalCubicInterpolator.HcalCubicInterpolator(), HcalShapeIntegrator.HcalShapeIntegrator(), QualityCutsAnalyzer::histogram_element_t.histogram_element_t(), CSCMake2DRecHit.hitFromStripAndWire(), HLTConfigDataEx.HLTConfigDataEx(), HLTMuonIsoFilter.HLTMuonIsoFilter(), HLTMuonPFIsoFilter.HLTMuonPFIsoFilter(), tmtt::HTrphi.HTrphi(), l1ct::PFRegion.hwGlbEtaOf(), l1ct::PFRegion.hwGlbPhiOf(), Matriplex.hypot(), i2str(), edm::service.i2str(), identity(), gen::Pythia6Hadronizer.imposeProperTime(), TMatacq.init(), Thrust.init(), cond::FileBasedEmptySource.initialize(), PerformancePayloadFromBinnedTFormula.initialize(), CosmicMuonSmoother.initialState(), edm::EventSelector.initPathNames(), trklet::TrackletLUT.initProjectionBend(), edm::DetSetVector< TotemRPLocalTrack::FittedRecHit >.insert(), HBHEHitMap.insert(), edm::JobReport::JobReportImpl.insertInputForOutputs(), lumi::TRGWBM2DB.int2str(), lumi::TRGScalers2DB.int2str(), HcalPulseShape.integrate(), CastorPulseShapes::Shape.integrate(), HLLHCEvtVtxGenerator.intensity(), LinearGridInterpolator3D.interpolate(), ConstantStepOdeSolver.interpolateCoordinate(), ConstantStepOdeSolver.interpolateIntegrated(), MatacqDataFormatter.interpretRawData(), CaloHitMaker.intersect(), DDSolidFactory.intersection(), ROOT::Math::Transform3DPJ.Inverse(), l1ct::PFRegion.isFiducial(), PerformancePayloadFromTable.isInPayload(), l1ct::PFRegion.isInside(), StackingAction.isItOutOfTimeWindow(), PerformancePayloadFromBinnedTFormula.isOk(), PerformancePayloadFromTFormula.isOk(), Phase2L1GMT::Isolation.isolation_allmu_alltrk(), CSCBaseValidation.isSimTrackGood(), HcalSpecialTimes.isSpecial(), CosmicMuonUtilities.isTraversing(), SimG4HcalValidation.jetAnalysis(), trklet::VarBase.kstring(), l1ct::multififo_regionizer::local_eta_phi_window< l1ct::TkObjEmu >(), L1GObject.L1GObject(), L1RPCConeDefinitionProducer.L1RPCConeDefinitionProducer(), mkfit::Shell.LabelFromHits(), ticl::LinkingAlgoByDirectionGeometric.linkTracksters(), trklet::TrackletCalculatorDisplaced.LLDSeeding(), trklet::TrackletCalculatorDisplaced.LLLSeeding(), LMFSeqDat.LMFSeqDat(), TmpSimEvent.load(), FSimEvent.load(), HistogramManager.loadFromDQMStore(), HcalGeomParameters.loadGeometry(), l1ct::multififo_regionizer.local_eta_phi_window(), LTCDigi.locTime(), funct.log(), HLTPerformanceInfo.longestModuleCPUTime(), HLTPerformanceInfo.longestModuleCPUTimeName(), HLTPerformanceInfo.longestModuleTime(), HLTPerformanceInfo.longestModuleTimeName(), LookInStream_SeekTo(), GroupedTrajCandLess.looperPenalty(), LzmaDec_DecodeReal(), main(), TFileDirectory.make(), edm::RandomtXiGunProducer.make_particle(), ticl::GeneralInterpretationAlgo.makeCandidates(), edm::eventsetup::DataKey.makeCopyOfMemory(), FWRPZViewGeometry.makeShape(), L1TPhase2GMTEndcapStubProcessor.makeStubs(), ticl::PatternRecognitionbyCLUE3D< TILES >.makeTracksters(), ticl::PatternRecognitionbyCA< TILES >.makeTracksters(), ticl::PatternRecognitionbyFastJet< TILES >.makeTracksters(), CSCStubMatcher.match(), CSCDigiMatcher.match(), GEMRecHitMatcher.match(), GEMDigiMatcher.match(), MuonSimHitMatcher.match(), CSCRecHitMatcher.match(), gen::TauolappInterface.MatchedLHESpinUp(), PerformancePayloadFromTable.matches(), BPHMonitor.matchToTrigger(), Matriplex.max(), l1ct::multififo_regionizer::EtaPhiBuffer< T >.maybe_push(), DTTime2DriftParametrization.MB_DT_delta_x(), GEMStripTopology.measurementError(), CSCRadialStripTopology.measurementError(), TkRadialStripTopology.measurementError(), TkRadialStripTopology.measurementPosition(), MeasurementTrackerEventProducer.MeasurementTrackerEventProducer(), Matriplex.min(), TFParams.mixShape(), FWEventItem.modelInfo(), CTPPSProtonReconstructionPlotter::MultiRPPlots.MultiRPPlots(), tmtt::MuxHToutputs.MuxHToutputs(), DDEcalBarrelAlgo.mytrap(), DDEcalBarrelNewAlgo.mytrap(), CmsTrackerStringToEnum.name(), cms::dd.name(), cms::dd.name_from_value(), WeightedMeanFitter.nearestPoint(), FWEveViewManager.newItem(), HLLHCEvtVtxGenerator.newVertex(), now(), SimG4HcalValidation.nxNAnalysis(), CaloSamples.offsetTime(), onePulse(), FWDetailViewManager.openDetailViewFor(), LMFCorrVers.operator!=(), LMFSeqVers.operator!=(), RunModeDef.operator!=(), RunTypeDef.operator!=(), RunSeqDef.operator!=(), DCUTag.operator!=(), MonRunTag.operator!=(), LMFPrimVers.operator!=(), RunTag.operator!=(), CaliTag.operator!=(), LMFRunTag.operator!=(), cscdqm::HWStandbyType.operator!=(), Tm.operator!=(), PhiRangeSelector.operator()(), MuonTrackCut.operator()(), FreeFunctionSelector< T, f >.operator()(), TrackChargeSelector.operator()(), SeedChargeSelector.operator()(), HcalPulseShape.operator()(), MinFunctionSelector< T, fun >.operator()(), FunctionMinSelector< F >.operator()(), MaxFunctionSelector< T, fun >.operator()(), EtaRangeSelector.operator()(), EtMinSelector.operator()(), MaxSelector< T >.operator()(), MinSelector< T >.operator()(), PtMaxSelector.operator()(), FFTJetCorrectorResultFromTransient< MyJet >.operator()(), PtMinSelector.operator()(), PairSelector< S1, S2 >.operator()(), RangeSelector< T, fun >.operator()(), DetSetCounterSelector.operator()(), CastorPulseShapes::Shape.operator()(), OverlapExclusionSelector< C, T, O >.operator()(), PdgIdExcluder.operator()(), StringCutObjectSelector< reco::CaloJet, true >.operator()(), StringObjectFunction< reco::Candidate, true >.operator()(), IMASelector.operator()(), PdgIdSelector.operator()(), StatusSelector.operator()(), TrackWithVertexSelector.operator()(), AndSelector< S1, S2, S3, S4, S5 >.operator()(), OrSelector< S1, S2, S3, S4, S5 >.operator()(), HcalCubicInterpolator.operator()(), TrajectoryFilter.operator()(), AndSelector< S1, S2, helpers::NullAndOperand, helpers::NullAndOperand, helpers::NullAndOperand >.operator()(), OrSelector< S1, S2, helpers::NullOrOperand, helpers::NullOrOperand, helpers::NullOrOperand >.operator()(), edm::OStreamColumn.operator()(), OrSelector< S1, S2, S3, helpers::NullOrOperand, helpers::NullOrOperand >.operator()(), AndSelector< S1, S2, S3, helpers::NullAndOperand, helpers::NullAndOperand >.operator()(), ConversionTrackFinder::ExtractNumOfHits.operator()(), Selector< pat::Electron >.operator()(), ConversionTrackFinder::ExtractChi2.operator()(), std::hash_specialization< Head, ndims >.operator()(), OrSelector< S1, S2, S3, S4, helpers::NullOrOperand >.operator()(), cms::cuda::detail::pointer_setter< I >.operator()(), RecoTrackSelectorBase.operator()(), AndSelector< S1, S2, S3, S4, helpers::NullAndOperand >.operator()(), std::hash_specialization< float >.operator()(), reco::parser::AnyMethodArgumentFixup.operator()(), std::hash< std::tuple< Head, ndims... > >.operator()(), L1TrackSelectionProducer::TTTrackPtMinSelector.operator()(), L1TrackSelectionProducer::TTTrackWordPtMinSelector.operator()(), L1TrackVertexAssociationProducer::TTTrackDeltaZMaxSelector.operator()(), VersionedSelector< T >.operator()(), VertexTrackEqual< N >.operator()(), L1TrackSelectionProducer::TTTrackAbsEtaMaxSelector.operator()(), InterpolatedPulse< 1500U >.operator()(), L1TrackVertexAssociationProducer::TTTrackWordDeltaZMaxSelector.operator()(), L1TrackSelectionProducer::TTTrackWordAbsEtaMaxSelector.operator()(), reco::parser::AnyMethodArgument2VoidPtr.operator()(), L1TrackSelectionProducer::TTTrackAbsZ0MaxSelector.operator()(), L1TrackSelectionProducer::TTTrackWordAbsZ0MaxSelector.operator()(), L1TrackVertexAssociationProducer::NNTrackWordSelector.operator()(), L1TrackSelectionProducer::TTTrackNStubsMinSelector.operator()(), L1TrackSelectionProducer::TTTrackWordNStubsMinSelector.operator()(), L1TrackSelectionProducer::TTTrackNPSStubsMinSelector.operator()(), L1TrackSelectionProducer::TTTrackPromptMVAMinSelector.operator()(), L1TrackSelectionProducer::TTTrackWordPromptMVAMinSelector.operator()(), L1TrackSelectionProducer::TTTrackBendChi2MaxSelector.operator()(), L1TrackVertexAssociationProducer::TTTrackWordLinkLimitSelector.operator()(), L1TrackSelectionProducer::TTTrackWordBendChi2MaxSelector.operator()(), L1TrackSelectionProducer::TTTrackChi2RZMaxSelector.operator()(), L1TrackSelectionProducer::TTTrackWordChi2RZMaxSelector.operator()(), L1TrackSelectionProducer::TTTrackChi2RPhiMaxSelector.operator()(), L1TrackSelectionProducer::TTTrackWordChi2RPhiMaxSelector.operator()(), L1TrackSelectionProducer::TTTrackChi2RZMaxNstubSelector.operator()(), L1TrackSelectionProducer::TTTrackWordChi2RZMaxNstubSelector.operator()(), L1TrackSelectionProducer::TTTrackChi2RPhiMaxNstubSelector.operator()(), L1TrackSelectionProducer::TTTrackWordChi2RPhiMaxNstubSelector.operator()(), L1TrackSelectionProducer::TTTrackBendChi2MaxNstubSelector.operator()(), L1TrackSelectionProducer::TTTrackWordBendChi2MaxNstubSelector.operator()(), ROOT::Math::Transform3DPJ.operator()(), operator*(), Matriplex.operator*(), ROOT::Math::Transform3DPJ.operator*(), VectorDoublet< Vector3D, Vector3D >.operator*=(), Vector2DBase< float, GlobalTag >.operator*=(), Vector3DBase< Scalar, GlobalTag >.operator*=(), Basic2DVector< float >.operator*=(), Basic3DVector< align::Scalar >.operator*=(), ROOT::Math::Transform3DPJ.operator*=(), Matriplex.operator+(), Matriplex.operator-(), operator/(), Matriplex.operator/(), VectorDoublet< Vector3D, Vector3D >.operator/=(), Vector2DBase< float, GlobalTag >.operator/=(), Vector3DBase< Scalar, GlobalTag >.operator/=(), Basic2DVector< float >.operator/=(), Basic3DVector< long double >.operator/=(), Basic3DVector< align::Scalar >.operator/=(), Tm.operator<(), L1GObject.operator<(), cscdqm::HistoDef.operator<(), operator<<(), tmtt::PrintL1trk.operator<<(), edm::MessageSender.operator<<(), cond::persistency::EchoedLogStream< EdmLogger >.operator<<(), cond::persistency::EchoedLogStream< edm::LogDebug_ >.operator<<(), edm.operator<<(), edm::Log< level::Debug, true >.operator<<(), cscdqm::LogCout.operator<<(), ROOT::Math.operator<<(), Tm.operator<=(), L1GObject.operator<=(), GenericTransientTrackingRecHit.operator=(), L1GObject.operator=(), edm::LimitedTaskQueue::Resumer.operator=(), cscdqm::HWStandbyType.operator=(), edm::service::ELlimitsTable.operator=(), edm::AssociationVector< KeyRefProd, CVal, KeyRef, SizeType, KeyReferenceHelper >.operator=(), cscdqm::HistoDef.operator=(), cscdqm::FEDHistoDef.operator=(), cscdqm::DDUHistoDef.operator=(), cscdqm::CSCHistoDef.operator=(), LMFCorrVers.operator==(), LMFSeqVers.operator==(), RunModeDef.operator==(), RunTypeDef.operator==(), DCUTag.operator==(), RunSeqDef.operator==(), MonRunTag.operator==(), RunTag.operator==(), LMFPrimVers.operator==(), LMFRunTag.operator==(), CaliTag.operator==(), cscdqm::HWStandbyType.operator==(), operator==(), Tm.operator==(), cscdqm::HistoDef.operator==(), L1GObject.operator==(), L1GObject.operator>(), L1GObject.operator>=(), edm::AssociationVector< KeyRefProd, CVal, KeyRef, SizeType, KeyReferenceHelper >.operator[](), edm::OStreamColumn.OStreamColumn(), ext::basic_omemstream< Item_t, Traits_t, Allocator_t >.overflow(), trklet::TrackletCalculatorBase.overlapSeeding(), cond::time.pack(), amc13::Packet.parse(), cond::persistency.parseTag(), InnerDeltaPhi.phiRange(), edm::SerialTaskQueue.pickNextTask(), PixelClusterCountsAuditor.PixelClusterCountsAuditor(), PixelUnpackingRegions.PixelUnpackingRegions(), DTPosNegType.pnCode(), DTPosNeg.pnCode(), poly< T >.poly(), trackerTFP::HoughTransform.pop_front(), trackerTFP::GeometricProcessor.pop_front(), trackerTFP::ZHoughTransform.pop_front(), trackerTFP::MiniHoughTransform.pop_front(), trackerTFP::KalmanFilter.pop_front(), trklet::KFin.pop_front(), trklet::DRin.pop_front(), edm::service.popStack(), edm::service::Timing.postCommon(), edm::service::Timing.postEndJob(), edm::service::StallMonitor.postEvent(), edm::service::StallMonitor.postEventReadFromSource(), edm.postIndexIntoFilePrintEventLists(), edm.postIndexIntoFilePrintEventsInLumis(), edm::service::Timing.postModuleEvent(), edm::service::StallMonitor.postModuleEventPrefetching(), edm::service::StallMonitor.postModuleStreamTransition(), edm::service::StallMonitor.postSourceEvent(), QIE8Simulator.preampOutput(), edm::service::StallMonitor.preEvent(), edm::service::StallMonitor.preEventReadFromSource(), edm::DelayedReaderInputProductResolver.prefetchAsync_(), edm::UnscheduledProductResolver.prefetchAsync_(), edm::TransformingProductResolver.prefetchAsync_(), CSCChipSpeedCorrectionDBConditions.prefillDBChipSpeedCorrection(), edm::service::StallMonitor.preModuleEvent(), edm::service::StallMonitor.preModuleEventAcquire(), edm::service::StallMonitor.preModuleGlobalTransition(), edm::service::StallMonitor.preModuleStreamTransition(), fireworks.prepareCandidate(), EMShower.prepareSteps(), fireworks.prepareTrack(), edm::service::StallMonitor.preSourceEvent(), trklet::VarAdjustK.print(), trklet::VarAdjustKR.print(), trklet::VarParam.print(), trklet::VarDef.print(), trklet::VarAdd.print(), trklet::VarSubtract.print(), trklet::VarNounits.print(), trklet::VarShiftround.print(), trklet::VarShift.print(), trklet::VarNeg.print(), trklet::VarTimesC.print(), trklet::VarMult.print(), trklet::VarInv.print(), cond::persistency.print_timestamp(), mkfit::Event.print_tracks(), trklet::VarBase.print_truncation(), PerformancePayloadFromBinnedTFormula.printFormula(), PerformancePayloadFromTFormula.printFormula(), printFrame(), CTPPSGeometryInfo.printGeometry(), EcalSelectiveReadoutProducer.printSrFlags(), TracksterLinksProducer.printTrackstersDebug(), TrackstersMergeProducer.printTrackstersDebug(), MultiVertexFitter.printWeights(), Phase2L1GMT::KMTF.process(), HBHEPhase1Reconstructor.processData(), EcalLaserCondTools.processIov(), edm::RandomtXiGunProducer.produce(), JetTracksAssociationDRVertex.produce(), JetVetoedTracksAssociationDRVertex.produce(), JetTracksAssociationDRVertexAssigned.produce(), JetTracksAssociationDRCalo.produce(), ECFAdder.produce(), PFTICLProducer.produce(), edm::ProductFromFwdPtrProducer< T, H >.produce(), ReducedESRecHitCollectionProducer.produce(), HLTTauMCProducer.produce(), SimTauProducer.produce(), EcalDetIdToBeRecoveredProducer.produce(), HLTCollectionProducer< T >.produce(), ReducedRecHitCollectionProducer.produce(), NjettinessAdder.produce(), BSCTrigger.produce(), PATObjectCrossLinker.produce(), HcalHitSelection.produce(), NanoAODBaseCrossCleaner.produce(), EcalSimpleProducer.produce(), L1TCaloLayer1.produce(), Phase2L1CaloEGammaEmulator.produce(), ConversionProducer.produce(), CTPPSRecHitProducer.produce(), L1TCaloSummary< INPUT, OUTPUT >.produce(), MatacqProducer.produce(), Strip1DMeasurementTransformator.projectionMatrix(), ticl::GeneralInterpretationAlgo.propagateTrackster(), ticl::LinkingAlgoByDirectionGeometric.propagateTrackster(), pulse(), pulse_raw(), pulse_x0(), pulse_x0_yz(), pulse_yz(), EcalUncalibRecHitFixedAlphaBetaAlgo< EBDataFrame >.pulseShapeFunction(), edm::EDCollection< T >.push_back(), edm::ProcessHistory.push_back(), edm::DetSet< StripDigiSimLink >.push_back(), DynArray< T >.push_back(), edm::SortedCollection< EcalRecHit >.push_back(), reco::TaggingVariableList.push_back(), edm::ProcessHistory.push_front(), l1ct::multififo_regionizer.push_to_fifo(), fireworks.pushNearbyPixelHits(), fireworks.pushPixelHits(), edm::SerialTaskQueue.pushTask(), CSCTriggerPrimitivesBuilder.put(), GsfTrackProducerBase.putInEvt(), TrackProducerWithSCAssociation.putInEvt(), CocoaToDDLMgr.pv(), PrimaryVertexMonitor.pvTracksPlots(), GeneralPurposeVertexAnalyzer.pvTracksPlots(), mkfit::StdSeq.qfilter_n_hits(), mkfit::StdSeq.qfilter_n_hits_pixseed(), mkfit::StdSeq.qfilter_n_layers(), mkfit::StdSeq.qfilter_nan_n_silly(), mkfit::StdSeq.qfilter_pixelLessBkwd(), mkfit::StdSeq.qfilter_pixelLessFwd(), ClusterShapeTrajectoryFilter.qualityFilter(), TtFullLepKinSolver.quartic(), cms::alpakatools.radixSortImpl(), edm::RandomEngineSentry< T >.RandomEngineSentry(), mkfit::Event.read_in(), LmfSource.readEventWithinFile(), MuonResiduals6DOFrphiFitter.readNtuple(), MuonResiduals5DOFFitter.readNtuple(), MuonResiduals6DOFFitter.readNtuple(), L1TPFCaloProducer.readPhase2BarrelCaloTowers_(), EcalLaserCondTools::FileReader.readTime(), SiStripTkMaps.readVertices(), MuonTrackingRegionByPtBuilder.region(), MuonTrackingRegionBuilder.region(), l1ct::multififo_regionizer::RegionMux< l1ct::EmCaloObjEmu >.RegionMux(), VertexFitterManager.registerFitter(), RntDumper.RegisterTree(), edm::WaitingTaskHolder.release_no_decrement(), HepMCValidationHelper.removeIsolatedLeptons(), edm::path_configuration.removeSchedulingTokensFromModuleLabel(), L1GctGlobalHfSumAlgos.resetPipelines(), CastorSimpleRecAlgo.resetTimeSamples(), tmtt::ChiSquaredFit4.residuals(), BtoCharmDecayVertexMergerT< VTX >.resolveBtoDchain(), edm::SerialTaskQueue.resume(), Phase1PixelMaps.retrieveCorners(), edm::RootFile.RootFile(), gen::PyquenHadronizer.rotateEvtPlane(), ConstantStepOdeSolver.run(), mkfit.runBtpCe_MultiIter(), CSCDigiValidator.sanitizeWireDigis(), TagProbeFitter.saveEfficiencyPlots(), PHcalTB06Info.saveHit(), PHcalTB04Info.saveHit(), GroupedTrajCandLess.score(), CTPPSFastTrackingProducer.SearchTrack(), InterpolatedPulse< 1500U >.secondDerivative(), LMFUnique.sequencePostfix(), JsonOutputProducer::JsonEventState.serialise(), FEDTrailer.set(), edm::service::SimpleMemoryCheck::SignificantEvent.set(), hitfit::Lepjets_Event.set_jet_types(), mkfit::LayerInfo.set_layer_type(), ticl::Trackster.setBoundaryTime(), TFHeaderDescription.setBunchCrossing(), MuonPathAnalyzerInChamber.setBxTolerance(), RunIOV.setByTime(), HLTPerformanceInfo::Module.setCPUTime(), L1GlobalTriggerEvmReadoutRecord.setDecision(), L1GlobalTriggerReadoutRecord.setDecision(), CaloTower.setEcalTime(), TFHeaderDescription.setFedEventNumber(), TFHeaderDescription.setFedId(), TFHeaderDescription.setFedType(), CaloTower.setHcalTime(), FWTableWidget.SetHeaderBackgroundColor(), FWTableWidget.SetHeaderForegroundColor(), MaterialBudgetData.setHGCalmode(), RunDCSHVDat.setHV(), RunDCSHVDat.setHVNominal(), reco::CaloMuon.setInnerTrack(), FWTableWidget.SetLineSeparatorColor(), RunDCSLVDat.setLV(), RunDCSLVDat.setLVNominal(), RunDCSMagnetDat.setMagnetCurrent(), MaterialBudgetData.setMtdmode(), TFHeaderDescription.setNumberOfChannels(), TFHeaderDescription.setNumberOfSamples(), l1t::PhysicsToBitConverter.SetObject(), setPaveTextStyle(), BaseParticlePropagator.setProperDecayTime(), cond::FileBasedEmptySource.setRunAndEventInfo(), HBHEChannelInfo.setSample(), PFECALSuperClusterAlgo.setSatelliteThreshold(), RunDCSLVDat.setStatus(), RunDCSHVDat.setStatus(), RunPTMTempDat.setTemperature(), PPSDiamondG4Hit.setThetaAtEntry(), FP420G4Hit.setThetaAtEntry(), TotemRPG4Hit.setThetaAtEntry(), BscG4Hit.setThetaAtEntry(), TotemG4Hit.setThetaAtEntry(), PPSPixelG4Hit.setThetaAtEntry(), CTPPSTimingRecHit.setTime(), HFShowerG4Hit.setTime(), FiberG4Hit.setTime(), CastorShowerEvent.setTime(), HLTPerformanceInfo::Module.setTime(), PassiveHit.setTime(), PCaloHit.setTime(), CTPPSTimingLocalTrack.setTime(), pat::PackedCandidate.setTime(), ticl::Trackster.setTimeAndError(), LMFLmrSubIOV.setTimes(), RunDCSLVDat.setTimeStatus(), RunDCSHVDat.setTimeStatus(), Tm.setToCurrentGMTime(), Tm.setToCurrentLocalTime(), Tm.setToGMTime(), Tm.setToLocalTime(), Tm.setToMicrosTime(), trklet::TrackDer.settpar(), CurrentG4Track.setTrack(), reco::CaloMuon.setTrack(), CoreSimTrack.setTrackId(), MuonPath.setTWireTDC(), FWGeoTopNode.setupBuffMtx(), edm::service::tracer.setupFile(), edm::service::moduleAlloc.setupFile(), edm::AssociationVector< KeyRefProd, CVal, KeyRef, SizeType, KeyReferenceHelper >.setValue(), PPSDiamondG4Hit.setVx(), FP420G4Hit.setVx(), TotemRPG4Hit.setVx(), TotemG4Hit.setVx(), PPSPixelG4Hit.setVx(), PPSDiamondG4Hit.setVy(), FP420G4Hit.setVy(), TotemRPG4Hit.setVy(), TotemG4Hit.setVy(), PPSPixelG4Hit.setVy(), PPSDiamondG4Hit.setVz(), FP420G4Hit.setVz(), TotemRPG4Hit.setVz(), TotemG4Hit.setVz(), PPSPixelG4Hit.setVz(), PPSDiamondG4Hit.setX(), FP420G4Hit.setX(), BscG4Hit.setX(), TotemRPG4Hit.setX(), TotemG4Hit.setX(), PPSPixelG4Hit.setX(), PPSDiamondG4Hit.setY(), FP420G4Hit.setY(), TotemRPG4Hit.setY(), BscG4Hit.setY(), TotemG4Hit.setY(), PPSPixelG4Hit.setY(), PPSDiamondG4Hit.setZ(), FP420G4Hit.setZ(), BscG4Hit.setZ(), TotemRPG4Hit.setZ(), TotemG4Hit.setZ(), PPSPixelG4Hit.setZ(), funct.sgn(), ME0PreRecoNoSmearModel.simulateSignal(), funct.sin(), Matriplex.sin(), SiPixelStatusProducer.SiPixelStatusProducer(), CosmicMuonSmoother.smooth(), edm::SerialTaskQueue.spawn(), DAClusterizerInZ_vect.split(), DAClusterizerInZT_vect.split(), SplittingConfigurableHisto.SplittingConfigurableHisto(), sqr(), RKCurvilinearDistance< T, N >.sqr(), FastCircleFit.sqr(), RZLine.sqr(), Matriplex.sqr(), funct.sqrt(), Matriplex.sqrt(), edm::shared_memory::WorkerMonitorThread.startThread(), EulerOdeSolver.step(), RK2.step(), RK4.step(), edm::ChildrenCPUTimer.stop(), edm::WallclockTimer.stop(), edm::CPUTimer.stop(), edm::EventProcessor.streamEndLumiAsync(), stringify(), cscdqm.stringToNumber(), DDSolidFactory.subtraction(), edm::service::ELstatistics.summaryForJobReport(), CSCAnalogSignal.superimpose(), BPHDecayToResTrkBuilderBase.swap(), funct.tan(), Matriplex.tan(), TrackWithVertexSelector.testTrack(), TrackWithVertexSelector.testVertices(), FTLCluster.time(), ME.time_high(), ME.time_low(), CastorHitCorrection.timeBin(), TotemTimingConversions.timeOfFirstSample(), EcalLaserCondTools.timeToString(), FWCollectionSummaryWidget.toggleShowHide(), l1ct::Tau.toGT(), cscdqm.toString(), LmfSource.toString(), LaserSorter.toString(), HLTPerformanceInfo.totalCPUTime(), QIE8Simulator.totalIntegratedCharge(), HLTPerformanceInfo.totalPathCPUTime(), HLTPerformanceInfo.totalPathTime(), HLTPerformanceInfo.totalTime(), TPGCheck.TPGCheck(), mkfit::StdSeq.track_print(), trklet::FitTrack.trackFitChisq(), MuonTrackAnalyzer.tracksAnalysis(), reco::JetTracksAssociation.tracksP4(), CosmicMuonSmoother.trajectory(), HcalDetIdTransform.transform(), FullModelReactionDynamics.TwoCluster(), PlotAlignmentValidation.twotailedStudentTTestEqualMean(), reco.typeCode(), ShallowTree::TypedBranchConnector< T >.TypedBranchConnector(), edm::service.ui2str(), DDSolidFactory.unionSolid(), tier0.unique(), FrontierCondition_GT_autoExpress_cfi.unique(), unit(), l1t::stage1::TauUnpackerLeft.unpack(), l1t::stage1::legacy::TauUnpacker.unpack(), l1t::stage1::IsoTauUnpackerLeft.unpack(), l1t::stage1::legacy::IsoTauUnpacker.unpack(), l1t::stage1::TauUnpackerRight.unpack(), l1t::stage1::IsoTauUnpackerRight.unpack(), RctRawToDigi.unpackCTP7(), DummyVertexTrackUpdator< N >.update(), fwlite::RecordWriter.update(), CastorShowerLibraryMaker.update(), EcalSelectiveReadoutValidation.updateL1aRate(), TriggerOutputFields.updateTriggerFields(), LTCDigi.utcTime(), MuonTrackCut.value(), cms::dd.value(), L1TCorrelatorLayer1Producer.vecRegInput(), L1TCorrelatorLayer1Producer.vecSecInput(), ConfigurableVertexFitter.vertex(), AbstractConfFitter.vertex(), l1tVertexFinder::RecoVertex< T >.vertex(), PrimaryVertexMonitor.vertexPlots(), GeneralPurposeVertexAnalyzer.vertexPlots(), ConfigurableAdaptiveReconstructor.vertices(), ConfigurableTrimmedKalmanFinder.vertices(), ReconstructorFromFitter.vertices(), ConfigurableVertexReconstructor.vertices(), VertexReconstructor.vertices(), ConfigurableMultiVertexFitter.vertices(), AdaptiveVertexReconstructor.vertices(), TrimmedVertexFinder.vertices(), reco::btag.weight(), NanoAODOutputModule.write(), writeABIOFileHeader(), writeABSRFFileHeader(), writeABTTFFileHeader(), FEConfigFgrParamDat.writeArrayDB(), FEConfigWeightGroupDat.writeArrayDB(), FEConfigFgrGroupDat.writeArrayDB(), FEConfigParamDat.writeArrayDB(), FEConfigOddWeightGroupDat.writeArrayDB(), MonPedestalsDat.writeArrayDB(), MonMemTTConsistencyDat.writeArrayDB(), MonTestPulseDat.writeArrayDB(), MonTTConsistencyDat.writeArrayDB(), MonPNLed2Dat.writeArrayDB(), MonPNGreenDat.writeArrayDB(), MonPNBlueDat.writeArrayDB(), MonPNMGPADat.writeArrayDB(), MonPNRedDat.writeArrayDB(), MonPNIRedDat.writeArrayDB(), MonPNLed1Dat.writeArrayDB(), DCULVRVoltagesDat.writeArrayDB(), ConstantStepOdeSolver.writeHistory(), ConstantStepOdeSolver.writeIntegrated(), edm::OutputModuleCommunicatorT< T >.writeLumiAsync(), NanoAODOutputModule.writeLuminosityBlock(), edm::OutputModuleCommunicatorT< T >.writeProcessBlockAsync(), NanoAODOutputModule.writeRun(), edm::OutputModuleCommunicatorT< T >.writeRunAsync(), FWRecoGeometryESProducer.writeTrackerParametersXML(), EcalDccWeightBuilder.writeWeightToRootFile(), HcalPulseShapes.Y11203(), HcalPulseShapes.Y11206(), MatacqProducer.~MatacqProducer(), and Trend.~Trend().

◆ template_cfg_file

submitPVValidationJobs.template_cfg_file = os.path.join(self.CMSSW_dir,"src/Alignment/OfflineValidation/test","PVValidation_T_cfg.py")

Definition at line 447 of file submitPVValidationJobs.py.

◆ text

string submitPVValidationJobs.text
Initial value:
1 = '''\n
2  process.conditionsIn{record} = CalibTracker.Configuration.Common.PoolDBESSource_cfi.poolDBESSource.clone(
3  connect = cms.string('{database}'),
4  toGet = cms.VPSet(cms.PSet(record = cms.string('{record}'),
5  tag = cms.string('{tag}'),
6  label = cms.untracked.string('{label}')
7  )
8  )
9  )
10  process.prefer_conditionsIn{record} = cms.ESPrefer("PoolDBESSource", "conditionsIn{record}")
11  '''.format(record = element, database = params[0], tag = params[1], label = (params[2] if len(params)>2 else ''))

Definition at line 484 of file submitPVValidationJobs.py.

Referenced by FWDialogBuilder.addCheckbox(), FWDialogBuilder.addLabel(), FWDialogBuilder.addTextButton(), HLTPrescaleExample.analyze(), l1t::L1TStage2CaloAnalyzer.analyze(), l1t::L1TGlobalAnalyzer.analyze(), JetHtPlotConfiguration.autoExpandEnvironmentVariables(), tmtt::TMTrackProducer.beginRun(), FWTrackHitsDetailView.build(), FWConvTrackHitsDetailView.build(), tmtt::TrackerModule.calcModuleType(), lhef::LHEReader::XMLHandler.characters(), SiPhase2BadStripConfigurableFakeESSource.clusterizeBadChannels(), SiPhase2BadStripChannelBuilder.clusterizeBadChannels(), CmsShowHelpPopup.CmsShowHelpPopup(), dd_to_html(), Filter.descriptionText(), tmtt::KFbase.doKF(), Comparator.Draw(), Phase1PixelROCMaps.drawBarrelMaps(), Phase1PixelROCMaps.drawForwardMaps(), Phase1PixelROCMaps.drawMaps(), JetHtPlotConfiguration.expandEnvironmentVariables(), tmtt::KFbase.fit(), fireworks.getLocalTime(), fireworks.getTimeGMT(), MagneticFieldGrid.gridType(), tmtt::HTrphi.HTrphi(), DetIdInfo.info(), fireworks.info(), tmtt::KFParamsComb.isGoodState(), main(), tmtt::MuxHToutputs.MuxHToutputs(), XMLDocument.newValue(), edm.operator<<(), triggerExpression.parse(), PlotAlignmentValidation.plotOutlierModules(), tmtt::StubWindowSuggest.printResults(), tmtt::KFbase.printStub(), tmtt::KFbase.printStubLayers(), tmtt::KFbase.printTP(), edm::service::RandomNumberGeneratorService.readStatesFromFile(), FWGUIValidatingTextEntry.showOptions(), and edm::DocFormatHelper.wrapAndPrintText().

◆ textToWrite

string submitPVValidationJobs.textToWrite = ''

now for the extra conditions

Definition at line 480 of file submitPVValidationJobs.py.

◆ the_dir

submitPVValidationJobs.the_dir

Definition at line 401 of file submitPVValidationJobs.py.

◆ theBaseName

def submitPVValidationJobs.theBaseName = None

Definition at line 989 of file submitPVValidationJobs.py.

◆ theBashDir

submitPVValidationJobs.theBashDir = None

Definition at line 988 of file submitPVValidationJobs.py.

◆ theDataSet

def submitPVValidationJobs.theDataSet = dataset.split("/")[1]+"_"+(dataset.split("/")[2]).split("-")[0]

Definition at line 369 of file submitPVValidationJobs.py.

◆ thejobIndex

list submitPVValidationJobs.thejobIndex = None

Definition at line 996 of file submitPVValidationJobs.py.

◆ theLogDir

submitPVValidationJobs.theLogDir = os.path.join(os.getcwd(),"log")

create the log directory

Definition at line 1072 of file submitPVValidationJobs.py.

◆ theLumi

string submitPVValidationJobs.theLumi = '1'

Definition at line 997 of file submitPVValidationJobs.py.

◆ totalJobs

int submitPVValidationJobs.totalJobs = 0

Definition at line 987 of file submitPVValidationJobs.py.

◆ tracktype

list submitPVValidationJobs.tracktype = []

Definition at line 395 of file submitPVValidationJobs.py.

◆ ttrhtype

list submitPVValidationJobs.ttrhtype = []

Definition at line 397 of file submitPVValidationJobs.py.

◆ USER

submitPVValidationJobs.USER = os.environ.get('USER')

Definition at line 652 of file submitPVValidationJobs.py.

◆ vertextype

list submitPVValidationJobs.vertextype = []

Definition at line 394 of file submitPVValidationJobs.py.