CMS 3D CMS Logo

Classes | Functions | Variables
runTheMatrix Namespace Reference

Classes

class  TheMatrix
 

Functions

def runSelected (opt)
 
def showRaw (opt)
 
def stepOrIndex (s)
 

Variables

 _
 
 action
 
 apply
 
 choices
 
 cmssw_base
 
 command
 
 const
 
 cudart_basename
 
 cudart_version
 
 default
 
 dest
 
 err
 
 formatter_class
 
 gpugroup
 
 help
 
 ibeos_cache
 
 keep
 
 libcudart
 
 mapped
 
 nargs
 
 opt
 
 out
 
 overWrite
 
 parser
 
 predefinedSet
 
 rerunthese
 
 ret
 prodAgent to be discontinued More...
 
 testList
 
 to_run
 
 type
 
 usage
 

Function Documentation

◆ runSelected()

def runTheMatrix.runSelected (   opt)

Definition at line 20 of file runTheMatrix.py.

References join(), genParticles_cff.map, and print().

20 def runSelected(opt):
21 
22  mrd = MatrixReader(opt)
23  mrd.prepare(opt.useInput, opt.refRel, opt.fromScratch)
24 
25  # test for wrong input workflows
26  if opt.testList:
27  definedWf = [dwf.numId for dwf in mrd.workFlows]
28  definedSet = set(definedWf)
29  testSet = set(opt.testList)
30  undefSet = testSet - definedSet
31  if len(undefSet)>0: raise ValueError('Undefined workflows: '+', '.join(map(str,list(undefSet))))
32  duplicates = [wf for wf in testSet if definedWf.count(wf)>1 ]
33  if len(duplicates)>0: raise ValueError('Duplicated workflows: '+', '.join(map(str,list(duplicates))))
34 
35  ret = 0
36  if opt.show:
37  mrd.show(opt.testList, opt.extended, opt.cafVeto)
38  if opt.testList : print('testListected items:', opt.testList)
39  else:
40  mRunnerHi = MatrixRunner(mrd.workFlows, opt.nProcs, opt.nThreads)
41  ret = mRunnerHi.runTests(opt)
42 
43  if opt.wmcontrol:
44  if ret!=0:
45  print('Cannot go on with wmagent injection with failing workflows')
46  else:
47  wfInjector = MatrixInjector(opt,mode=opt.wmcontrol,options=opt.wmoptions)
48  ret= wfInjector.prepare(mrd,
49  mRunnerHi.runDirs)
50  if ret==0:
51  wfInjector.upload()
52  wfInjector.submit()
53  return ret
54 
55 # ================================================================================
56 
def runSelected(opt)
Definition: runTheMatrix.py:20
void print(TMatrixD &m, const char *label=nullptr, bool mathematicaFormat=false)
Definition: Utilities.cc:47
static std::string join(char **cmd)
Definition: RemoteFile.cc:19

◆ showRaw()

def runTheMatrix.showRaw (   opt)

Definition at line 11 of file runTheMatrix.py.

11 def showRaw(opt):
12 
13  mrd = MatrixReader(opt)
14  mrd.showRaw(opt.useInput, opt.refRel, opt.fromScratch, opt.raw, opt.step1Only, selected=opt.testList)
15 
16  return 0
17 
18 # ================================================================================
19 
def showRaw(opt)
Definition: runTheMatrix.py:11

◆ stepOrIndex()

def runTheMatrix.stepOrIndex (   s)

Definition at line 459 of file runTheMatrix.py.

References createfilelist.int.

459  def stepOrIndex(s):
460  if s.isdigit():
461  return int(s)
462  else:
463  return s
def stepOrIndex(s)

Variable Documentation

◆ _

runTheMatrix._
private

◆ action

runTheMatrix.action

Definition at line 200 of file runTheMatrix.py.

◆ apply

runTheMatrix.apply

Definition at line 465 of file runTheMatrix.py.

◆ choices

runTheMatrix.choices

Definition at line 263 of file runTheMatrix.py.

◆ cmssw_base

runTheMatrix.cmssw_base

◆ command

runTheMatrix.command

Definition at line 417 of file runTheMatrix.py.

◆ const

runTheMatrix.const

Definition at line 374 of file runTheMatrix.py.

Referenced by TkGluedMeasurementDet::HitCollectorForRecHits.addProjected(), TkGluedMeasurementDet::HitCollectorForSimpleHits.addProjected(), TkGluedMeasurementDet::HitCollectorForFastMeasurements.addProjected(), cms.Adler32(), edm::soa::impl::ConstTableItrAdvance< I, Args >.advance(), edm::soa::impl::ConstTableItrAdvance< 0, Args... >.advance(), SiStripGainFromData.algoBeginJob(), ecaldqm::RecoSummaryTask.analyze(), ecaldqm::ClusterTask.analyze(), B2GDQM.analyzeJets(), PFElecTkProducer.applySelection(), JetTracksAssociationXtrpCalo.associateInputTracksToJet(), BaseTrackerRecHit.BaseTrackerRecHit(), BeamSpotOnline.BeamSpotOnline(), edm::SoATuple< edm::EDConsumerBase::TokenLookupInfo, bool, edm::EDConsumerBase::LabelPlacement, edm::KindOfType >.begin(), SiStripDetInfoFileWriter.beginRun(), NearbyPixelClustersAnalyzer.beginRun(), BoundDiskSector.bounds(), BarrelDetLayer.bounds(), ForwardDetLayer.bounds(), RPCConeBuilder.buildCones(), SeedForPhotonConversion1Leg.buildSeed(), GroupedCkfTrajectoryBuilder.buildTrajectories(), DAFTrackProducerAlgorithm.calculateNdof(), edm.checkClassDictionaries(), ctfseeding::HitExtractorSTRP.cleanedOfClusters(), edm::soa::TableView< Args >.column(), edm::ProcessBlock.commit_(), edm::LuminosityBlock.commit_(), edm::Run.commit_(), edm::Event.commit_(), edm.convert_handle(), edm.convert_handle_check_type(), MkFitOutputConverter.convertCandidates(), DAFTrackProducerAlgorithm.countingGoodHits(), BareRootProductGetter.createNewBuffer(), edm::ProductResolverBase::Resolution.data(), edm::reftobase::RefVectorHolder< REFV >::const_iterator_imp_specific.dc(), DcsStatus.DcsStatus(), CaloTowersCreationAlgo.ecalChanStatusForCaloTower(), edm::SoATuple< edm::EDConsumerBase::TokenLookupInfo, bool, edm::EDConsumerBase::LabelPlacement, edm::KindOfType >.end(), MRHChi2MeasurementEstimator.estimate(), pat::JetCorrFactorsProducer.evaluate(), edm::test::TestProcessor.event(), edm::EventForOutput.eventPrincipal(), edm::Event.eventPrincipal(), edm::soa::TableView< Args >.fillArray(), cms::PileupJPTJetIdAlgo.fillJPTBlock(), edm::FilterWrapper< T >.filter(), DAFTrackProducerAlgorithm.filter(), SiStripDigitizer.finalizeEvent(), ElectronMVAEstimatorRun2.findCategory(), PFElecTkProducer.findPfRef(), SiTrackerMultiRecHit.firstClusterRef(), edm::test::ProcessBlock.get(), edm::test::Run.get(), edm::test::Event.get(), edm::test::LuminosityBlock.get(), edm::soa::RowView< Args >.get(), edm::soa::TableView< Args >.get(), edm::soa::MutableRowView< Args >.get(), edm::eventsetup::DependentRecordImplementation< EcalMappingRcd, edm::mpl::Vector< EcalMappingElectronicsRcd > >.get(), PortableHostMultiCollection< TestSoA, TestSoA2 >.get(), PortableDeviceMultiCollection< TDev, T0, Args >.get(), edm::SoATuple< edm::EDConsumerBase::TokenLookupInfo, bool, edm::EDConsumerBase::LabelPlacement, edm::KindOfType >.get(), edm::soa::Table< edm::soa::col::Pt, edm::soa::col::Eta, edm::soa::col::Phi, edm::soa::col::Vz >.get(), TrajAnnealing.getAnnealingWeight(), fwlite::LuminosityBlockBase.getByLabelImpl(), fwlite::RunBase.getByLabelImpl(), fwlite::EventBase.getByLabelImpl(), ECFAdder.getECF(), edm::eventsetup::EventSetupRecordImpl.getImplementation(), BareRootProductGetter.getIt(), edm.getProduct(), edm::refcore.getProduct_(), edm::refcore.getProductWithCoreFromRef_(), edm::reftobase::RefHolderBase.getPtr(), edm::refitem::GetRefPtrImpl< C, T, F, KEY >.getRefPtr_(), edm::refitem::GetRefPtrImpl< C, T, F, unsigned int >.getRefPtr_(), NjettinessAdder.getTau(), fwlite::DataGetterHelper.getThinnedAssociation(), BareRootProductGetter.getThinnedAssociation(), edm::EventPrincipal.getThinnedAssociation(), edm::refcore.getThinnedProduct_(), GlobalCosmicMuonTrajectoryBuilder.getTransientRecHits(), TrackTransformer.getTransientRecHits(), GlobalTrajectoryBuilderBase.getTransientRecHits(), CosmicHitPairGeneratorFromLayerPair.hitPairs(), RectangularEtaPhiTrackingRegion.hits(), MultiHitGeneratorFromChi2.hitSets(), PFHFRecHitCreator.importRecHits(), CosmicLayerTriplets.init(), SiStripDetVOffFakeBuilder.initialize(), PreMixingSiStripWorker.initializeEvent(), SiStripDigitizer.initializeEvent(), edm::reftobase::Holder< T, REF >.isEqualTo(), edm::reftobase::IndirectHolder< T >.isEqualTo(), edm::Wrapper< math::XYZVectorD >.isProductEqual_(), PFElecTkProducer.isSameEgSC(), PFElecTkProducer.isSharingEcalEnergyWithEgSC(), L1TriggerScalers.L1TriggerScalers(), Level1TriggerScalers.Level1TriggerScalers(), LowPtGsfElectronSeedProducer.loop(), edm::LuminosityBlockForOutput.luminosityBlockPrincipal(), edm::LuminosityBlock.luminosityBlockPrincipal(), LumiScalers.LumiScalers(), edm::WorkerMaker< T >.makeWorker(), TkPixelMeasurementDet.measurements(), edm::Wrapper< math::XYZVectorD >.mergeProduct_(), edm::DeviceProductBase.metadata(), ALPAKA_ACCELERATOR_NAMESPACE::ecal::raw::Kernel_unpack.operator()(), edm::Ptr< CaloRecHit >.operator*(), edm::Ptr< CaloRecHit >.operator->(), edm::ESGetToken< L1TriggerKeyList, L1CaloEcalScaleRcd >.operator=(), edm.pointerToBase(), edm::TypeWithDict.pointerToBaseType(), edm::PoolOutputModule.preActionBeforeRunEventAsync(), edm::ProductSelector.print(), edm::ProcessBlock.processBlockPrincipal(), DeDxDiscriminatorLearner.processHit(), DeDxHitInfoProducer.processHit(), DeDxEstimatorProducer.processHit(), StandaloneTrackMonitor.processHit(), FastTrackDeDxProducer.processHit(), JetTracksAssociationExplicit.produce(), SiStripHashedDetIdESModule.produce(), JetTracksAssociatorAtCaloFace.produce(), MuonReducedTrackExtraProducer.produce(), FastTSGFromL2Muon.produce(), JPTJetSlimmer.produce(), PFTrackProducer.produce(), TrackerCleaner< T >.produce(), OnlineMetaDataRawToDigi.produce(), TkMSParameterizationBuilder.produce(), MkFitOutputConverter.produce(), PFElecTkProducer.produce(), GoodSeedProducer.produce(), SiStripRegionConnectivity.produceRegionCabling(), edm::OrphanHandle< reco::TrackCollection >.product(), edm::TestHandle< T >.product(), edm::Handle< edm::ValueMap< std::pair< float, float > > >.product(), edm::ESTransientHandle< T >.product(), edm::ESHandle< MuonDetLayerGeometry >.product(), edm::refcoreimpl.productGetter(), edm::refcoreimpl.productPtr(), TrackingRecHitPropagator.project(), TkGluedMeasurementDet.projectOnGluedDet(), edm::reftobase::RefVectorHolder< REFV >.push_back(), edm::PtrVector< reco::CaloCluster >.push_back(), edm::ProcessBlockPrincipal.put(), edm::LuminosityBlockPrincipal.put(), edm::RunPrincipal.put(), edm::EventPrincipal.put(), edm::Principal.put_(), edm::EventPrincipal.putOnRead(), edm::RunPrincipal.putOrMerge(), FedRawDataInputSource.read(), DataModeFRD.readEvent(), DataModeFRDStriped.readEvent(), GroupedCkfTrajectoryBuilder.rebuildSeedingRegion(), TkPhase2OTMeasurementDet.recHits(), RecHitsSortedInPhi.RecHitsSortedInPhi(), edm::Ref< L1GctEmCandCollection >.Ref(), GlobalMuonRefitter.refit(), edm::stream::impl::Transformer.registerTransform(), edm::one::impl::Transformer< T >.registerTransform(), edm::limited::impl::Transformer< T >.registerTransform(), edm::global::impl::Transformer< T >.registerTransform(), edm::stream::impl::Transformer.registerTransformAsync(), edm::one::impl::Transformer< T >.registerTransformAsync(), edm::limited::impl::Transformer< T >.registerTransformAsync(), edm::global::impl::Transformer< T >.registerTransformAsync(), PFElecTkProducer.resolveGsfTracks(), SimpleDAFHitCollector.rightdimension(), PortableHostMultiCollection< TestSoA, TestSoA2 >.ROOTReadStreamer(), edm::RunForOutput.runPrincipal(), edm::Run.runPrincipal(), cond::serialization::SerializationHelper< T, INIT >.serialize(), cond::serialization::SerializationHelper< T, INIT >.serialize_impl(), edm::refcoreimpl.setCacheIsProductGetter(), FRDStreamSource.setRunAndEventInfo(), GlobalMuonRefitter.setServices(), TrackTransformer.setServices(), SimpleDAFHitCollector.SimpleDAFHitCollector(), SiTrackerMultiRecHitUpdator.SiTrackerMultiRecHitUpdator(), TkStackMeasurementDet.specificGeomDet(), TkDoubleSensMeasurementDet.specificGeomDet(), TkGluedMeasurementDet.specificGeomDet(), TkPhase2OTMeasurementDet.specificGeomDet(), TkPixelMeasurementDet.specificGeomDet(), TkStripMeasurementDet.specificGeomDet(), reco::PFCandidate.storeRefInfo(), TCDSRecord.TCDSRecord(), FastTSGFromIOHit.trackerSeeds(), TrajAnnealing.TrajAnnealing(), SeedForPhotonConversionFromQuadruplets.trajectorySeed(), edm::refcore.tryToGetProductWithCoreFromRef_(), L1GtfeExtWord.unpack(), L1GtfeWord.unpack(), L1TcsWord.unpack(), L1GtFdlWord.unpack(), edmNew::DetSetVector< SiStripCluster >.update(), fwlite::DataGetterHelper.wrapperBasePtr(), and VirtualJetProducer.writeJets().

◆ cudart_basename

runTheMatrix.cudart_basename

Definition at line 394 of file runTheMatrix.py.

◆ cudart_version

runTheMatrix.cudart_version

Definition at line 391 of file runTheMatrix.py.

◆ default

runTheMatrix.default

Definition at line 152 of file runTheMatrix.py.

◆ dest

runTheMatrix.dest

Definition at line 151 of file runTheMatrix.py.

◆ err

runTheMatrix.err

Definition at line 436 of file runTheMatrix.py.

◆ formatter_class

runTheMatrix.formatter_class

Definition at line 147 of file runTheMatrix.py.

◆ gpugroup

runTheMatrix.gpugroup

Definition at line 367 of file runTheMatrix.py.

◆ help

runTheMatrix.help

Definition at line 150 of file runTheMatrix.py.

◆ ibeos_cache

runTheMatrix.ibeos_cache

Definition at line 434 of file runTheMatrix.py.

◆ keep

runTheMatrix.keep

Definition at line 467 of file runTheMatrix.py.

Referenced by CaloHitResponse.add(), ThirdHitPrediction.calculateRanges(), ThirdHitPrediction.calculateRangesBarrel(), ThirdHitPrediction.calculateRangesForward(), tmtt::L1track3D.cheat(), Phase2L1GMT::ROITempAssociator.clean(), L1TMuonBarrelKalmanSectorProcessor.cleanNeighbor(), L1TMuonBarrelKalmanSectorProcessor.cleanNeighbors(), TrackCleaner.cleanTracks(), L1TPhase2GMTEndcapStubProcessor.combineStubs(), trklet::TrackletCalculatorDisplaced.DDLSeeding(), tmtt::MiniHTstage.exec(), tmtt::MuxHToutputs.exec(), NanoAODRNTupleOutputModule.fillDescriptions(), NanoAODOutputModule.fillDescriptions(), DQMRootOutputModule.fillDescriptions(), HcalSiPMHitResponse.finalizeHits(), ThirdHitPrediction.findArcIntersection(), HLTCSCOverlapFilter.hltFilter(), PFHBHERecHitCreator.importRecHits(), PFHcalRecHitCreator< Digi, Geometry, Layer, Detector >.importRecHits(), PFPSRecHitCreator.importRecHits(), PFHGCalRecHitCreator< DET, Layer, det, subdet >.importRecHits(), PFHFRecHitCreator.importRecHits(), PFEcalBarrelRecHitCreator.importRecHits(), PFEcalEndcapRecHitCreator.importRecHits(), NanoAODRNTupleOutputModule.initializeNTuple(), trklet::TrackletCalculatorBase.inSector(), tmtt::HTrphi.killTracksBusySec(), trklet::TrackletCalculatorDisplaced.LLDSeeding(), trklet::TrackletCalculatorDisplaced.LLLSeeding(), GlobalCosmicMuonTrajectoryBuilder.match(), trklet::MatchProcessor.matchCalculator(), NanoAODRNTupleOutputModule.openFile(), NanoAODOutputModule.openFile(), reco::tau::RecoTauTwoProngFilter.operator()(), PPSFilteredProtonProducer.produce(), ReducedEGProducer.produce(), CosmicMuonTrajectoryBuilder.selectHits(), GlobalMuonRefitter.selectMuonHits(), ThirdHitPrediction.ThirdHitPrediction(), trklet::FitTrack.trackFitChisq(), and edm::ThinnedAssociationsHelper.updateFromParentProcess().

◆ libcudart

runTheMatrix.libcudart

Definition at line 392 of file runTheMatrix.py.

◆ mapped

runTheMatrix.mapped

◆ nargs

runTheMatrix.nargs

Definition at line 373 of file runTheMatrix.py.

◆ opt

runTheMatrix.opt

◆ out

runTheMatrix.out

Definition at line 436 of file runTheMatrix.py.

◆ overWrite

runTheMatrix.overWrite

Definition at line 490 of file runTheMatrix.py.

◆ parser

runTheMatrix.parser

Definition at line 147 of file runTheMatrix.py.

◆ predefinedSet

runTheMatrix.predefinedSet

Definition at line 60 of file runTheMatrix.py.

◆ rerunthese

runTheMatrix.rerunthese

Definition at line 420 of file runTheMatrix.py.

◆ ret

runTheMatrix.ret

prodAgent to be discontinued

Definition at line 759 of file runTheMatrix.py.

Referenced by PI.__attribute__(), cms::cuda::AtomicPairCounter.__attribute__(), __attribute__(), reco::formula::UnaryMinusEvaluator.abstractSyntaxTree(), reco::formula::FunctionTwoArgsEvaluator.abstractSyntaxTree(), reco::formula::FunctionOneArgEvaluator.abstractSyntaxTree(), reco::formula::BinaryOperatorEvaluator< Op >.abstractSyntaxTree(), FilterSelection.acceptMap(), cms::alpakatools::AtomicPairCounter.add(), FWTTreeCache.AddBranchTopLevel(), TrajectorySegmentBuilder.addGroup(), edm::ProductRegistry.addLabelAlias(), edm::ProductRegistry.addProduct(), edm::ProductRegistry.aliasToModules(), aligned_alloc(), pat::EventHypothesis.all(), pat::TriggerObjectStandAlone.allLabels(), mkfit::CcPool< mkfit::TrackCand >.allocate(), cond::service::PoolDBOutputService.appendSinceTime(), SlidingPeakFinder.apply(), apply(), PixelInactiveAreaFinder::InactiveAreas.areasAndLayerSets(), VertexAssociatorByPositionAndTracks.associateRecoToSim(), VertexAssociatorByPositionAndTracks.associateSimToReco(), associationMapFilterValues(), cms::cudacompat.atomicAdd(), cms::cudacompat.atomicAnd(), cms::cudacompat.atomicInc(), cms::cudacompat.atomicMax(), atomicMaxF(), atomicMaxPair(), cms::cudacompat.atomicMin(), cms::cudacompat.atomicOr(), cms::cudacompat.atomicSub(), cond::auth::Cipher.b64decrypt(), cond::auth::Cipher.b64encrypt(), base64_decode(), base64_encode(), cond::persistency::Query< Types... >.begin(), EGEnergyCorrectorFactoryFromEventSetup.build(), edm::TypeWithDict.byName(), gpuCalibPixel.calibDigis(), calloc(), FWTableViewTableManager.cellRenderer(), edm::storage::StorageFactory.check(), LMFDat.check(), PFAlgo.checkAndReconstructSecondaryInteraction(), popcon::EcalLaserHandler.checkAPDPN(), popcon::EcalLaserHandler.checkAPDPNs(), DTCalibrationMap.checkGranularity(), mkfit::Shell.CheckMkFitLayerPlanVsReferenceHits(), AdaptiveVertexReconstructor.cleanUp(), AdaptiveVertexReconstructor.cleanUpVertices(), LHCInfoPerFill.cloneFill(), LHCInfo.cloneFill(), DCCTBEventBlock.compare(), DCCTBBlockPrototype.compare(), BeamSpotCompatibilityChecker.compareBS(), edm::eventsetup::EventSetupRecordImpl.componentsForRegisteredDataKeys(), edm::streamer::StreamSerializer.compressBuffer(), computeAverageRMS(), PortableHostMultiCollection< TestSoA, TestSoA2 >.computeDataSize(), PortableDeviceMultiCollection< TDev, T0, Args >.computeDataSize(), computeMinRMS(), edm::ConditionalTaskHelper.conditionalModuleBranches(), edm::ParameterTypeTraits< std::vector< std::pair< std::string, T > > >.convert(), MkFitSeedConverter.convertSeeds(), TtFullHadKinFitter::KinFit.corJet(), FSQ::HandlerTemplate< TInputCandidateType, TOutputCandidateType, filter >.count(), pat::strbitset.count(), ConstrainedTreeBuilderT.covarianceMatrix(), JetIDSelectionFunctor.craft08Cuts(), cond::CredentialStore.createSchema(), Qjets.d_ij(), reco::NamedCompositeCandidate.daughter(), reco::CompositeCandidate.daughter(), DDCompareBoolSol(), DDCompareCPV(), DDCompareDBLVEC(), DDCompareDDRot(), DDCompareDDRotMat(), DDCompareDDTrans(), DDCompareEPV(), DDCompareLP(), DDCompareSolid(), HDF5ProductResolver.decompress_zlib(), cond::auth::Cipher.decrypt(), spu.def(), detid_compare(), beamSpotPI::BSParamsHelper< PayloadType >.diffCentralValues(), simBeamSpotPI::SimBSParamsHelper< PayloadType >.diffCentralValues(), beamSpotPI::BSParamsHelper< PayloadType >.diffErrors(), pat::helper::ParametrizationHelper.diffToParameters(), edm.DisableLoggedErrorsSummary(), l1t::TkJetWord.dispFlagWord(), dot(), dot2(), FWTTreeCache.DropBranch(), FWTTreeCache.DropBranchTopLevel(), pat::GenericDuplicateRemover< Comparator, Arbitrator >.duplicates(), pat::PATObject< reco::Muon >.efficiencies(), egEnergyCorrectorFactoryFromRootFile(), edm.EnableLoggedErrorsSummary(), L1TCtL2EgProducer.encodeLayer1(), L1TCtL2EgProducer.encodeLayer1EgObjs(), l1ct::L2EgEncoderEmulator.encodeLayer2(), l1ct::L2EgEncoderEmulator.encodeLayer2_trivial(), l1ct::L2EgEncoderEmulator.encodeLayer2EgObjs(), l1ct::L2EgEncoderEmulator.encodeLayer2EgObjs_trivial(), edm::AssociativeIterator< KeyRefType, AssociativeCollection, ItemGetter >.end(), MuonGeometryArrange.endHist(), DCCTBEventBlock.eventErrorString(), DCCTBEventBlock.eventHasErrors(), cms::cuda.eventWorkHasCompleted(), evf::EvFFEDExcluder.EvFFEDExcluder(), cond::OMSServiceQuery.execute(), LMFUnique.exists(), MuonVPlusJetsIDSelectionFunctor.fall10Cuts(), edm::service::ProcInfoFetcher.fetch(), cond::persistency::PayloadReader.fetch(), l1tpf_calo::SingleCaloClusterer.fetch(), l1tpf_calo::SimpleCaloLinkerBase.fetch(), LMFSeqDat.fetchByRunNumber(), l1tpf_calo::SingleCaloClusterer.fetchCells(), L1TCorrelatorLayer1Producer.fetchDecodedTracks(), L1TCorrelatorLayer1Producer.fetchEmCalo(), EcalCondDBInterface.fetchFEDelaysForRun(), L1TCorrelatorLayer1Producer.fetchHadCalo(), LMFSeqDat.fetchLast(), EcalCondDBInterface.fetchLMFRunIOV(), cond::persistency::Session.fetchPayload(), L1TCorrelatorLayer1Producer.fetchPF(), edm::service::SimpleMemoryCheck.fetchSmaps(), L1TCorrelatorLayer1Producer.fetchTracks(), CounterChecker.Fill(), AlignPCLThresholdPlotHelper::AlignPCLThresholds_DisplayBase< PayloadType >.fill(), AlignPCLThresholdPlotHelper::AlignPCLThresholds_CompareBase< PayloadType, nIOVs, ntags >.fill(), beamSpotPI::DisplayParameters< PayloadType >.fill(), templateHelper::SiPixelTemplateHeaderInfo< PayloadType, StoreType, TransientType, myType, myParam >.fill(), simBeamSpotPI::DisplayParameters< PayloadType >.fill(), LzmaFile.FillArray(), LHEXMLStringProduct.fillCompressedContent(), reco::HitPattern.fillNewHitPatternWithOldHitPattern_v12(), StopAfterNEvents.filter(), SimpleEventFilter.filter(), SimpleJetFilter.filter(), AlignmentPI::topolInfo.filterThePartition(), SiPixelPI::topolInfo.filterThePartition(), CrossingPtBasedLinearizationPointFinder.find(), pat::GenericOverlapFinder< Distance >.find(), CaloSpecificAlgo.find_DetId_of_ECAL_cell_in_constituent_of(), CaloSpecificAlgo.find_DetId_of_HCAL_cell_in_constituent_of(), find_element_ref(), reco.findDataMember(), fwlite::EntryFinder.findEvent(), associationMapFilterValuesHelpers.findInsert(), fwlite::EntryFinder.findLumi(), FSQ::HandlerTemplate< TInputCandidateType, TOutputCandidateType, filter >.findPathAndFilter(), fwlite::EntryFinder.findRun(), HLTSumJetTag< T >.findTagValueByMinDeltaR2(), HLTJetTag< T >.findTagValueByMinDeltaR2(), ElectronVPlusJetsIDSelectionFunctor.firstDataCuts(), PFJetIDSelectionFunctor.firstDataCuts(), MuonVPlusJetsIDSelectionFunctor.firstDataCuts(), MultiVertexFitter.fit(), KFTrajectoryFitter.fitOne(), cond::persistency::RunInfoEditor.flush(), cond::persistency::GTEditor.flush(), cond::persistency::IOVEditor.flush(), DCCTBBlockPrototype.formatString(), approx_math.fpfloor(), cond::impl.from_string_impl(), FsmwClusterizer1DNameSpace.fsmw(), JetIDSelectionFunctor.fwd09Cuts(), pat::PATObject< reco::Muon >.genParticleRefs(), pat::Flags.get(), cond::payloadInspector::PlotAnnotations.get(), coral_bridge::AuthenticationCredentialSet.get(), SiStripPedestals.get10bits(), SiStripNoises.get9bits(), unrolledHisto.get_integral(), cond::OMSServiceResultRef.getArray(), pat::EventHypothesis.getAs(), PropagateToMuon.getBestDet(), Selector< pat::Electron >.getBitTemplate(), LMFColoredTable.getColor(), LMFDefFabric.getColor(), LMFDefFabric.getColorFromID(), LMFCorrCoefDat.getCorrections(), LHCInfoPopConSourceHandler.getCTPPSData(), LHCInfoPerLSPopConSourceHandler.getCTPPSData(), LHCInfoPerFillPopConSourceHandler.getCTPPSData(), pos::PixelGlobalDelay25.getCyclicDelay(), LMFDat.getData(), cond.getDbCredentials(), pos::PixelGlobalDelay25.getDelay(), LHCInfoPopConSourceHandler.getEcalData(), LHCInfoPerFillPopConSourceHandler.getEcalData(), EcalCondDBInterface.getEcalLogicID2LmrMap(), EcalCondDBInterface.getEcalLogicIDMappedTo(), DAQSource.getEventReport(), FedRawDataInputSource.getEventReport(), edm::streamer.getFRDFileHeaderVersion(), beamSpotPI::BeamSpot_history< my_param, PayloadType >.getFromPayload(), beamSpotPI::BeamSpot_runhistory< my_param, PayloadType >.getFromPayload(), beamSpotPI::BeamSpot_timehistory< my_param, PayloadType >.getFromPayload(), L1TMuon::GeometryTranslator.getGlobalPoint(), PFAnalysis.getHitPosition(), DCCTBDataParser.getIndexedData(), getInfoFromService(), edm::messagelogger::ELseverityLevel.getInputStr(), LMFUnique.getInt(), LMFLmrSubIOV.getIOVIDsLaterThan(), cond::persistency::IOVProxy.getLast(), cond::persistency::Session.getLastRun(), DTOccupancyCluster.getLayerIDs(), L1RPCConeBuilder::TCompressedCon.getLogStrip(), cond::persistency::IOVProxy.getMetadata(), TrackerMuonHitExtractor.getMuonHits(), edm::messagelogger::ELseverityLevel.getName(), edm::ELseverityLevel.getName(), VertexFitterManager.getNames(), VertexRecoManager.getNames(), DDLParser.getNameSpace(), Qjets.GetNextDistance(), cond.getNextSequenceValue(), DropBoxMetadata::Parameters.getParameter(), LMFCorrCoefDat.getParameters(), RPCPacData.getPatternsGroupDescription(), edm::pdtentry.getPdtEntryVector(), PCrossingFrame< T >.getPileups(), PhysicsTools::Calibration::MVAComputer.getProcessors(), SiStripMiscalibrate.getRegionsFromDetId(), LMFCorrCoefDat.getSubIOVIDs(), edm::messagelogger::ELseverityLevel.getSymbol(), LMFColoredTable.getSystem(), cond::service::PoolDBOutputService.getTagInfo(), fwlite::DataGetterHelper.getThinnedKeyFrom(), BareRootProductGetter.getThinnedKeyFrom(), edm::EventPrincipal.getThinnedKeyFrom(), FWTriggerTableViewTableManager.getTitles(), FWTableViewTableManager.getTitles(), RPCStripsRing.getTowerForRefRing(), pos::PixelGlobalDelay25.getTTCrxDelay(), PreparePVTrends.getUnrolledHisto(), cond::CredentialStore.getUserCredentials(), edm::MultiAssociation< C >.getValues(), edm::messagelogger::ELseverityLevel.getVarName(), JetCharge.getWeight(), L1GtTriggerMenuXmlParser.getXMLAttribute(), L1GtTriggerMenuXmlParser.getXMLTextValue(), l1t::TkJetWord.glbEtaWord(), l1t::TkJetWord.glbPhiWord(), LogErrorEventFilter.globalBeginLuminosityBlock(), evf::GlobalEvFOutputModule.globalBeginLuminosityBlock(), l1t.GlobalObjectStringToEnum(), evf::EvFDaqDirector.grabNextJsonFromRaw(), ecalpyutils.hashedIndexToEtaPhi(), ecalpyutils.hashedIndexToXY(), SeedingLayerSetsBuilder.hits(), SeedingLayerSetsHits.hits(), TrackingRecHitSoADevice< TrackerTraits >.hitsModuleStartToHostAsync(), HLTL1TMatchedJetsVBFFilter< T >.hltFilter(), hsm_1d(), hsm_1d_returning_iterators(), hsm_3d(), cond.httpGet(), l1ct::Tau.hwAbsIso(), l1ct::PFRegion.hwGlbPhi(), PixelInactiveAreaFinder.inactiveAreas(), L1TauEmu.inCone(), L1SCJetEmu.inCone(), spu.inf(), initialize(), OscarMTProducer.initializeGlobalCache(), edm::ScheduleItems.initSchedule(), reco::HitPattern.innermostMuonStationWithHits(), associationMapFilterValuesHelpers::IfFound< edm::Ref< C, T, F > >.insert(), associationMapFilterValuesHelpers::IfFound< edm::RefToBase< T > >.insert(), associationMapFilterValuesHelpers::IfFound< edm::RefVector< C, T, F > >.insert(), associationMapFilterValuesHelpers::IfFound< std::vector< std::pair< edm::Ref< C, T, F >, Q > > >.insert(), associationMapFilterValuesHelpers::IfFound< std::vector< std::pair< edm::RefToBase< T >, Q > > >.insert(), edm::FunctionWithDict.invoke(), reco::parser::MethodInvoker.invoke(), reco::parser::SingleInvoker.invoke(), reco::parser::LazyInvoker.invoke(), reco::parser::LazyInvoker.invokeLast(), cond::persistency::IOVProxy.iovSequenceInfo(), DTHitPairForFit.isCompatible(), DDLRotationAndReflection.isLeftHanded(), LMFRunTag.isValid(), LMFColor.isValid(), LMFSeqDat.isValid(), LMFRunIOV.isValid(), LMFClsDat.isValid(), LMFLaserPulseDat.isValid(), LMFPnPrimDat.isValid(), LMFPrimDat.isValid(), LMFDat.isValid(), reco::parser::ExpressionVar.isValidReturnType(), hitfit::Lepjets_Event.jet_types(), hitfit.jetTypeString(), MuonVPlusJetsIDSelectionFunctor.kitQCDCuts(), TrackingRegionsSeedingLayerSets::RegionLayers.layerPairs(), SeedingLayerSetsBuilder.layers(), cms::h5::DataSet.layout(), TrackingRecHitSoADevice< TrackerTraits >.localCoordToHostAsync(), main(), IsoDepositVetoFactory.make(), cond::auth::KeyGenerator.make(), cms::cuda.make_SimpleVector(), cms::alpakatools.make_SimpleVector(), SiStripCondTypes.makeBitSet(), makeDummyPayload(), helper::Parser.makeExpression(), theLHCInfoPerFillImpl.makeFillPayload(), theLHCInfoImpl.makeFillPayload(), LHCInfoPerLSPopConSourceHandler.makeFillPayload(), cond.makeIov(), PVValHelper.makeLogBins(), StripCompactDigiSimLinks.makeReverseMap(), SeedingLayerSetsBuilder.makeSeedingLayerSetsHitsforFastSim(), helper::Parser.makeSelector(), reco::parser::ExpressionVar.makeStorage(), malloc(), DTCalibValidation.map1DRecHitsPerWire(), DTRecHitQuality.map1DRecHitsPerWire(), GlobalRecHitsAnalyzer.map1DRecHitsPerWire(), GlobalRecHitsProducer.map1DRecHitsPerWire(), pat::Flags.maskToString(), TrackingNtuple.matchCluster(), median(), memalign(), TrackMerger.merge(), evf::MetaDataCache.MetaDataCache(), cms::cuda::allocator.minCachedBytes(), EcalCleaningAlgo.neighbours(), cond::service::PoolDBOutputService.newReadOnlySession(), cond::persistency::Query< Types... >.next(), l1t::TkJetWord.ntWord(), reco::parser::ExpressionVar.objToDouble(), edm::storage::StorageFactory.open(), pat.operator &(), operator new(), operator new[](), SubsetHsmModeFinder3d.operator()(), MtvClusterizer1D< T >.operator()(), FsmwClusterizer1D< T >.operator()(), MultiClusterizer1D< T >.operator()(), OutermostClusterizer1D< T >.operator()(), calibPixel::CalibDigis< debug >.operator()(), FsmwModeFinder3d.operator()(), PVSelector.operator()(), RunLumiSelector.operator()(), WSelector.operator()(), PVObjectSelector.operator()(), WPlusJetsEventSelector.operator()(), ElectronVPlusJetsIDSelectionFunctor.operator()(), VersionedSelector< T >.operator()(), Selector< pat::Electron >.operator()(), JetIDStudiesSelector.operator()(), PFMuonSelector.operator()(), ALPAKA_ACCELERATOR_NAMESPACE::ECLCCCompute1.operator()(), MuonVPlusJetsIDSelectionFunctor.operator()(), PFJetIDSelectionFunctor.operator()(), JetIDSelectionFunctor.operator()(), cond::persistency::GetFromRow< std::array< char, n > >.operator()(), SimpleCutBasedElectronIDSelectionFunctor.operator()(), Tm.operator+(), pat.operator^(), pat.operator|(), pat::strbitset.operator~(), VertexBeamspotOrigins.origins(), reco::HitPattern.outermostMuonStationWithHits(), pat::helper::ParametrizationHelper.p4fromParameters(), l1ct::Sum.pack(), l1ct::EGIsoObj.pack(), l1ct::HadCaloObj.pack(), cms::alpakatools::AtomicPairCounter.pack(), l1gt::ThreeVector.pack(), l1ct::Tau.pack(), l1ct::PFChargedObj.pack(), l1ct::EGIsoEleObj.pack(), l1ct::EmCaloObj.pack(), l1ct::PFNeutralObj.pack(), l1ct::PuppiObj.pack(), l1ct::TkObj.pack(), l1ct::PFRegion.pack(), l1gt::Electron.pack(), l1gt::Photon.pack(), l1ct::MuObj.pack(), l1ct::PVObj.pack(), l1ct::Jet.pack_ap(), l1gt::Jet.pack_ap(), l1gt::Sum.pack_ap(), l1gt::Tau.pack_ap(), edm::streamer::StreamerOutputMsgBuilders.parameters(), pat::helper::ParametrizationHelper.parametersFromP4(), Selector< pat::Electron >.passCut(), pat::PackedCandidate.phiAtVtx(), pat::helper::ParametrizationHelper.polarP4fromParameters(), l1ct::multififo_regionizer::EtaPhiBuffer< T >.pop(), posix_memalign(), pat::XGBooster.predict(), helper::ScannerBase.print(), TrackerMap.printall(), TrackerMap.printonline(), cms::DDCMSDetElementCreator.process(), PFAnalysis.processBlocks(), PreparePVTrends.processData(), ClusterCheckerEDProducer.produce(), TrackingParticleConversionRefSelector.produce(), JetChargeProducer.produce(), TrackingParticleBHadronRefSelector.produce(), TrackingParticleNumberOfLayersProducer.produce(), TrackingRegionEDProducerT< T_TrackingRegionProducer >.produce(), JetTracksAssociationToTrackRefs.produce(), pat::helper::AnythingToValueMap< Adaptor, Collection, value_type >.produce(), CandIsolatorFromDeposits.produce(), edmtest::DetSetVectorThingProducer.produce(), PFCandIsolatorFromDeposits.produce(), BufferedBoostIOESProducer< DataType, MyRecord >.produce(), pat::helper::ManyThingsToValueMaps< Adaptor, Collection, value_type >.produce(), l1ct::Scales.ptToInt(), l1t::TkJetWord.ptWord(), l1t::VertexWord.ptWord(), l1ct::Event.pv(), l1ct::Event.pv_emu(), pixelTrack.qualityByName(), Qjets.Rand(), RPCpg.rate(), SiStripApvGainFromFileBuilder.read_tickmark(), lhef::StorageInputStream.readBytes(), edm::storage::LocalFileSystem.readFSTypes(), evf::EvFDaqDirector.readLastLSEntry(), edm::OneLumiPoolSource.readLuminosityBlockAuxiliary_(), LzmaFile.ReadNextNumber(), cms::h5::Attribute.readUInt32(), realloc(), edm::eventsetup::EventSetupProvider.recordsToResolverIndices(), edm::eventsetup::EventSetupRecordProvider.registeredDataKeys(), helpers::CompositeCandidateMaker.release(), helpers::NamedCompositeCandidateMaker.release(), helpers::CompositePtrCandidateMaker.release(), cond::CredentialStore.resetAdmin(), PixelNtupletsFitter.run(), PixelFitterByHelixProjections.run(), TrackFitter.run(), cond::Utilities.run(), KFBasedPixelFitter.run(), METAlgo.run(), pat::helper::AnyNumberAssociationAdaptor.run(), pat::helper::AnyNumberAssociationAdaptor.run_(), TrackerMap.save_as_fectrackermap(), TrackerMap.save_as_HVtrackermap(), TrackerMap.save_as_psutrackermap(), riemannFit.scatterCovLine(), ALPAKA_ACCELERATOR_NAMESPACE::riemannFit.scatterCovLine(), cond.schemaLabel(), CocoaToDDLMgr.scrubString(), KDTreeLinkerPSEcal.searchLinks(), KDTreeLinkerTrackHcal.searchLinks(), KDTreeLinkerTrackEcal.searchLinks(), cond::persistency::RUN_INFO::Table.select(), cond::persistency::IOVProxy.selectAll(), cond::persistency::IOVProxy.selectRange(), cond::persistency::IOVProxy.sequenceSize(), cond.serialize(), edm::streamer::StreamerOutputModuleCommon.serializeEventMetaData(), cond::persistency.Session::storePayload< std::string >(), EcalElectronicsMapper.setActiveDCC(), EcalUncalibRecHitWorkerFixedAlphaBetaFit.setAlphaBeta(), Selector< pat::Electron >.setIgnored(), ticl::TracksterP4FromEnergySum.setP4(), pat::helper::ParametrizationHelper.setParametersFromAnyVector(), cond::CredentialStore.setPermission(), NearbyPixelClustersAnalyzer.setTopoInfo(), SiStripCondVisualizer.setTopoInfo(), ALPAKA_ACCELERATOR_NAMESPACE::ESProducer.setWhatProducedDevice(), muon.sharedSegments(), pat::MET.shiftedP2(), pat::MET.shiftedP2_74x(), pat::VertexAssociationSelector.simpleAssociation(), cond::OMSServiceResult.size(), PortableDeviceMultiCollection< TDev, T0, Args >.sizes(), PortableHostMultiCollection< TestSoA, TestSoA2 >.sizes(), DTtTrigDBValidation.slFromBin(), DTResolutionAnalysisTest.slFromBin(), DTResolutionTest.slFromBin(), PixelInactiveAreaFinder::InactiveAreas.spansAndLayerSets(), MuonVPlusJetsIDSelectionFunctor.spring10Cuts(), SimpleCutBasedElectronIDSelectionFunctor.spring10Variables(), PropagateToMuon.startingState(), MatcherUsingTracksAlgorithm.startingState(), edm::shared_memory::WorkerMonitorThread.startThread(), edm::storage::LocalFileSystem.statFSInfo(), lhef::StorageInputStream.StorageInputStream(), cond::persistency::Session.storePayload(), StringToEnumValue(), MuonVPlusJetsIDSelectionFunctor.summer08Cuts(), edm::storage::File.sysclose(), FWTableViewManager.tableFormats(), FWTableViewManager.tableFormatsImpl(), cond::service::PoolDBOutputService.tagInfo(), MatcherUsingTracksAlgorithm.targetState(), MaxLostHitsTrajectoryFilter.TBC(), MaxConsecLostHitsTrajectoryFilter.TBC(), MaxHitsTrajectoryFilter.TBC(), MaxCCCLostHitsTrajectoryFilter.TBC(), SeedExtensionTrajectoryFilter.TBC(), LostHitsFractionTrajectoryFilter.TBC(), LooperTrajectoryFilter.TBC(), ALPAKA_ACCELERATOR_NAMESPACE.testESAlgoAsync(), edmtest::ThinningDSVTestAnalyzer.ThinningDSVTestAnalyzer(), edmtest::ThinningTestAnalyzer.ThinningTestAnalyzer(), MinPtTrajectoryFilter.toBeContinued(), l1ct::TrackInputEmulator.toFloat_(), HeterogeneousSoA< T >.toHostAsync(), HeterogeneousSoAImpl< T, Traits >.toHostAsync(), PFMuonSelector.TopPag12LjetsCuts(), TrackerMap.TrackerMap(), TrajectoryBuilder.trajectories(), GroupedCkfTrajectoryBuilder.trajectories(), CosmicMuonTrajectoryBuilder.trajectories(), KFTrajectorySmoother.trajectory(), TangentApproachInRPhi.trajectoryParameters(), ClosestApproachInRPhi.trajectoryParameters(), edmtest::TransformAsyncIntProducer.TransformAsyncIntProducer(), edmtest::TransformAsyncIntStreamProducer.TransformAsyncIntStreamProducer(), edm::EventBase.triggerNames_(), edm::streamer::StreamerInputSource.uncompressBuffer(), edm::streamer::StreamerInputSource.uncompressBufferZSTD(), l1ct::Sum.unpack(), l1ct::EGIsoObj.unpack(), l1ct::HadCaloObj.unpack(), l1ct::Tau.unpack(), l1ct::PFChargedObj.unpack(), l1ct::EGIsoEleObj.unpack(), l1ct::EmCaloObj.unpack(), l1ct::PFNeutralObj.unpack(), l1ct::PuppiObj.unpack(), l1ct::PFRegion.unpack(), l1ct::TkObj.unpack(), l1ct::MuObj.unpack(), l1ct::PVObj.unpack(), l1ct::Jet.unpack_ap(), l1gt::ThreeVector.unpack_ap(), l1gt::Jet.unpack_ap(), l1gt::Sum.unpack_ap(), l1gt::Tau.unpack_ap(), l1gt::Electron.unpack_ap(), l1gt::Photon.unpack_ap(), spu.Unzip(), edm::ESProducer.updateFromMayConsumes(), cond::CredentialStore.updatePrincipal(), reco::parser::ExpressionVar.value(), reco::parser::ExpressionLazyVar.value(), HLTMuonPlotter.vector_to_string(), MultiVertexBSeeder.vertices(), ReconstructorFromFitter.vertices(), MultiVertexReconstructor.vertices(), AdaptiveVertexReconstructor.vertices(), popcon::PopCon.write(), edm::streamer::StreamerOutputFile.write(), L1TCorrelatorLayer1PatternFileWriter.writeBarrelGCT(), LHEXMLStringProduct.writeCompressedContent(), SummaryOutputProducer.writeCSV_module(), SummaryOutputProducer.writeCSV_trigger(), LMFCorrCoefDatComponent.writeDB(), LMFColoredTable.writeDB(), LMFDat.writeDB(), L1TCorrelatorLayer1PatternFileWriter.writeEgamma(), edm::streamer::StreamerOutputFile.writeEventFragment(), edm::streamer::StreamerOutputFile.writeEventHeader(), L1TCorrelatorLayer1PatternFileWriter.writeHGC(), edm::streamer::StreamerOutputFile.writeInitFragment(), edm::streamer::OutputFile.writePadding(), edm::streamer::StreamerOutputFile.writeStart(), L1TCorrelatorLayer1PatternFileWriter.writeTF(), l1t::TkJetWord.xtWord(), l1t::TkJetWord.z0Word(), l1t::VertexWord.z0Word(), spu.zerr(), and omt::ThreadHandoff.~ThreadHandoff().

◆ testList

runTheMatrix.testList

Definition at line 429 of file runTheMatrix.py.

◆ to_run

runTheMatrix.to_run

Definition at line 424 of file runTheMatrix.py.

◆ type

runTheMatrix.type

Definition at line 157 of file runTheMatrix.py.

◆ usage

runTheMatrix.usage

Definition at line 145 of file runTheMatrix.py.