CMS 3D CMS Logo

 All Classes Namespaces Files Functions Variables Typedefs Enumerations Enumerator Properties Friends Macros Pages
Functions | Variables
edmStreamStallGrapher Namespace Reference

Functions

def getTime
 
def sumSort
 

Variables

tuple f = open(fileName,"r")
 
list fileName = sys.argv[1]
 
 foundEventToStartFrom = False
 
int maxNameSize = 0
 
tuple name = l.split("'")
 
int numStreams = 0
 
list oldState = streamState[s]
 
tuple priorities = list()
 
tuple processingSteps = list()
 
string s
 
 seenInit = False
 
dictionary stalledModules = {}
 
int startTime = 0
 
string states = "%-*s: "
 
tuple stream = int( l[l.find("stream = ")+9])
 
list streamState = [1]
 
list streamTime = [0]
 
tuple t = stalledModules.setdefault(n,[])
 
tuple time = getTime(l)
 
int trans = 0
 
 waitTime = None
 

Function Documentation

def edmStreamStallGrapher.getTime (   line)

Definition at line 39 of file edmStreamStallGrapher.py.

39 
40 def getTime(line):
41  time = line.split(" ")[1]
42  time = time.split(":")
43  time = int(time[0])*60*60+int(time[1])*60+float(time[2])
44  return time
def edmStreamStallGrapher.sumSort (   i,
  j 
)

Definition at line 120 of file edmStreamStallGrapher.py.

121 def sumSort(i,j):
122  return cmp(i[1],j[1])
123 priorities.sort(cmp=sumSort, reverse=True)

Variable Documentation

tuple edmStreamStallGrapher.f = open(fileName,"r")

Definition at line 37 of file edmStreamStallGrapher.py.

list edmStreamStallGrapher.fileName = sys.argv[1]

Definition at line 35 of file edmStreamStallGrapher.py.

edmStreamStallGrapher.foundEventToStartFrom = False

Definition at line 49 of file edmStreamStallGrapher.py.

tuple edmStreamStallGrapher.maxNameSize = 0

Definition at line 47 of file edmStreamStallGrapher.py.

tuple edmStreamStallGrapher.name = l.split("'")

Definition at line 66 of file edmStreamStallGrapher.py.

edmStreamStallGrapher.numStreams = 0

Definition at line 46 of file edmStreamStallGrapher.py.

list edmStreamStallGrapher.oldState = streamState[s]

Definition at line 85 of file edmStreamStallGrapher.py.

Referenced by edm::InputSource.nextItemType().

tuple edmStreamStallGrapher.priorities = list()

Definition at line 115 of file edmStreamStallGrapher.py.

tuple edmStreamStallGrapher.processingSteps = list()

Definition at line 45 of file edmStreamStallGrapher.py.

string edmStreamStallGrapher.s
Initial value:
1 = """Purpose: Convert a cmsRun log with Tracer info into a stream stall graph.
2 
3 To Use: Add the Tracer Service to the cmsRun job you want to check for stream stalls.
4  Make sure to use the 'printTimstamps' option
5  cms.Service("Tracer", printTimestamps = cms.untracked.bool(True))
6  After running the job, execute this script and pass the name of the log file to the
7  script as the only command line argument.
8 
9 To Read: The script will then print an 'ASCII art' stall graph which consists of the name of
10  the module which either started or stopped running on a stream, and the state of each
11  stream at that moment in time and if the module just started, you will also see the
12  amount of time on that stream between the previous module finishing and this module starting.
13  The state of a stream is represented by a symbol:
14  blank (" ") the stream is currently running a module
15  line ("|") the stream is waiting to run a module
16  star ("*") the stream has just finished waiting and is starting a module
17  If a module had to wait more than 0.1 seconds, the end of the line will have "STALLED".
18  Once the first 4 events have finished processing, the program prints "FINISH INIT".
19  This is useful if one wants to ignore stalled caused by startup actions, e.g. reading
20  conditions.
21 
22  Once the graph is completed, the program outputs the list of modules which had
23  the greatest total stall times. The list is sorted by total stall time and
24  written in descending order. In addition, the list of all stall times for the
25  module is given.
26 """

Definition at line 6 of file edmStreamStallGrapher.py.

edmStreamStallGrapher.seenInit = False

Definition at line 80 of file edmStreamStallGrapher.py.

dictionary edmStreamStallGrapher.stalledModules = {}

Definition at line 81 of file edmStreamStallGrapher.py.

edmStreamStallGrapher.startTime = 0

Definition at line 48 of file edmStreamStallGrapher.py.

Referenced by condPython.defineWhat< RPCObGas >(), condPython.defineWhat< RPCObImon >(), condPython.defineWhat< RPCObTemp >(), condPython.defineWhat< RPCObVmon >(), CSCBaseElectronicsSim.setSignalTimeRange(), and SubsystemNeutronWriter.writeHits().

string edmStreamStallGrapher.states = "%-*s: "

Definition at line 95 of file edmStreamStallGrapher.py.

Referenced by FastTimer.describe(), reco::GhostTrackFitter.fit(), RandomEngineStateProducer.globalBeginLuminosityBlockProduce(), reco::GhostTrackVertexFinder.initialVertices(), reco::TrackInfo.localTrackMomentum(), reco::TrackInfo.localTrackMomentumOnMono(), reco::TrackInfo.localTrackMomentumOnStereo(), reco::TrackInfo.localTrackPosition(), reco::TrackInfo.localTrackPositionOnMono(), reco::TrackInfo.localTrackPositionOnStereo(), MultiTrajectoryStateMode.momentumFromModeP(), TrackIPProducer.produce(), RandomEngineStateProducer.produce(), edm::service::RandomNumberGeneratorService.readFromEvent(), edm::service::RandomNumberGeneratorService.readFromLuminosityBlock(), reco::GhostTrackVertexFinder.refitGhostTrack(), TrackInfoProducerAlgorithm.run(), reco::TrackInfo.stateOnDet(), reco::TrackInfo.type(), SiStripPartition.update(), and CommissioningHistosUsingDb.uploadAnalyses().

tuple edmStreamStallGrapher.stream = int( l[l.find("stream = ")+9])

Definition at line 54 of file edmStreamStallGrapher.py.

Referenced by HLTrigReport.analyze(), BTagDifferentialPlot.bookHisto(), EtaPtBin.buildDescriptionString(), DQMStoreStats.calcIgProfDump(), LzmaFile.DecodeAll(), LzmaFile.DecodeBuffer(), DTOccupancyClusterBuilder.drawClusters(), pftools::CaloBox.dump(), HLTrigReport.endLuminosityBlock(), HLTrigReport.endRun(), cond::ExportIOVUtilities.execute(), FastTimerService.fillPathMap(), getABDCCOutputStream(), HLTMuonTrackMassFilter.hltFilter(), HLTMuonTrackMassFilter.HLTMuonTrackMassFilter(), L1GtPsbSetupConfigOnlineProd.numberFromString(), LzmaFile.Open(), operator<<(), pftools.operator<<(), reco.operator<<(), edm::ParentContext.ParentContext(), FastTimerService.postEvent(), FastTimerService.postModuleEvent(), FastTimerService.postModuleEventDelayedGet(), FastTimerService.postPathEvent(), FastTimerService.postSourceEvent(), FastTimerService.postStreamBeginLumi(), FastTimerService.postStreamBeginRun(), FastTimerService.postStreamEndLumi(), FastTimerService.postStreamEndRun(), FastTimerService.preallocate(), FastTimerService.preEvent(), FastTimerService.preGlobalBeginRun(), FastTimerService.preModuleBeginJob(), FastTimerService.preModuleEvent(), FastTimerService.preModuleEventDelayedGet(), FastTimerService.prePathEvent(), FastTimerService.preSourceEvent(), FastTimerService.preStreamBeginRun(), DQMStore.print_trace(), pftools::SpaceManager.printCalibrations(), QuarkoniaTrackSelector.produce(), L1RCTOmdsFedVectorProducer.produce(), QuarkoniaTrackSelector.QuarkoniaTrackSelector(), RunInfoRead.readData(), FastTimerService.reserveLuminosityPlots(), and edm::service::MessageLogger.unEstablishModule().

list edmStreamStallGrapher.streamState = [1]

Definition at line 77 of file edmStreamStallGrapher.py.

list edmStreamStallGrapher.streamTime = [0]

Definition at line 78 of file edmStreamStallGrapher.py.

tuple edmStreamStallGrapher.t = stalledModules.setdefault(n,[])

Definition at line 108 of file edmStreamStallGrapher.py.

Referenced by RunManager.abortEvent(), RunManagerMT.abortEvent(), CachingSeedCleanerByHitPosition.add(), CachingSeedCleanerBySharedInput.add(), DTVDriftCalibration::cellInfo.add(), popcon::PopConSourceHandler< CastorPedestals >.add(), HcalDetDiagLEDData.add_statistics(), HcalDetDiagLaserData.add_statistics(), TrajectorySegmentBuilder.addGroup(), fireworks.addRhoZEnergyProjection(), DeDxDiscriminatorLearnerFromCalibTree.algoAnalyzeTheTree(), CkfDebugger.analyseCompatibleMeasurements(), myFastSimVal.analyze(), TrackingTruthValid.analyze(), TrackingMaterialAnalyser.analyze(), HLTMonBTagIPSource.analyze(), HLTMonBTagMuSource.analyze(), WValidation.analyze(), ElectronSeedAnalyzer.analyze(), DrellYanValidation.analyze(), ValidationMisalignedTracker.analyze(), dEdxAnalyzer.analyze(), L1Scalers.analyze(), BeamMonitor.analyze(), L1TDTTPG.analyze(), TrackParameterAnalyzer.analyze(), L1TFED.analyze(), myJetAna.analyze(), HcalRecHitsAnalyzer.analyze(), HcalRecHitsValidation.analyze(), EcalSelectiveReadoutValidation.analyze(), PrimaryVertexAnalyzer.analyze(), LaserSorter.analyze(), PrimaryVertexAnalyzer4PU.analyze(), EcalSelectiveReadoutValidation.analyzeEB(), EcalSelectiveReadoutValidation.analyzeEE(), PrimaryVertexAnalyzer4PU.analyzeVertexCollection(), edm::WaitingTaskList.announce(), FWGeometryTableManagerBase.applyTransparencyFromEditor(), edm::HepMCProduct.applyVtxGen(), Signal.asgn(), EZMgrVL< T >.assign(), EZMgrFL< T >.assign(), EZArrayVL< T >.assign(), EZArrayFL< GlobalPoint >.assign(), helper::SimpleJetTrackAssociator.associate(), JetCrystalsAssociator.associate(), helper::SimpleJetTrackAssociator.associateTransient(), edm::AssociationVector< KeyRefProd, CVal, KeyRef, SizeType, KeyReferenceHelper >.AssociationVector(), DTDigitizer.asymGausSmear(), PhiSymmetryCalibration.beginJob(), LumiCalculator.beginRun(), PrimaryVertexAnalyzer4PU.bookVertexHistograms(), FWPFCandidateWithHitsProxyBuilder.build(), FWSecVertexProxyBuilder.build(), FWTrackingParticleProxyBuilder.build(), FWTrackingParticleProxyBuilderFullFramework.build(), FWPFCandidate3DProxyBuilder.build(), FWPFPatJet3DProxyBuilder< T >.build(), FWVertexProxyBuilder.build(), gen::HijingHadronizer.build_hijing_vertex(), gen::Hydjet2Hadronizer.build_hyjet2_vertex(), gen::HydjetHadronizer.build_hyjet_vertex(), TouchableToHistory.buildAll(), CmsTrackerDetIdBuilder.buildId(), TrackerGeomBuilderFromGeometricDet.buildPixel(), SiStripDetVOffBuilder.buildPSUdetIdMap(), TrackerGeomBuilderFromGeometricDet.buildSilicon(), FWTrackProxyBuilderFullFramework.buildTrack(), edm::TypeWithDict.byName(), Averages.calc(), CSCEventData.calcALCTcrc(), CSCStripAmpResponse.calculateAmpResponse(), JetPlusTrackProducerAA.calculateBGtracksJet(), CaloCachedShapeIntegrator.CaloCachedShapeIntegrator(), CSCDCCExaminer.check(), edm.checkDictionaries(), FWGeometryTableManager.checkRegionOfInterest(), MixingWorker.checkSignal(), edm::MixingWorker< T >.checkSignal(), SimTrackManager.cleanTracksWithHistory(), ora::SchemaUtils.cleanUp(), edm::AssociationVector< KeyRefProd, CVal, KeyRef, SizeType, KeyReferenceHelper >.clear(), edm::CopyPolicy< T >.clone(), LaserSorter.closeOutStream(), FWEveViewManager.colorsChanged(), EcalSelectiveReadoutValidation.compareSrfColl(), EMShower.compute(), converter::SuperClusterToCandidate.convert(), converter::StandAloneMuonTrackToCandidate.convert(), converter::TrackToCandidate.convert(), copyObject(), CSCStripElectronicsSim.createDigi(), LMFCorrVers.createObject(), LMFSeqVers.createObject(), LMFTrigType.createObject(), LMFIOV.createObject(), LMFPrimVers.createObject(), LMFRunTag.createObject(), MuonSeedFromRecHits.createSeed(), MuonSeedCreator.createSeed(), CosmicMuonSeedGenerator.createSeed(), cscClassPackerCompare(), MatRepSparse< T, D1, D2, S, F >.csink(), d2str(), edm::service.d2str(), MaterialBudgetData.dataPerStep(), FWLiteESSource.delaySettingRecords(), EMShower.deposit(), IntegralOverPhiFunction.DoEval(), reco::parser::AnyMethodArgumentFixup.doInt(), DDEcalPreshowerAlgo.doLadders(), DTConfigTraco.DTConfigTraco(), DTTMax.DTTMax(), DAClusterizerInZ.dump(), EcalLinearCorrectionsXMLTranslator.dumpXML(), EcalLaserAPDPNRatiosXMLTranslator.dumpXML(), EcalHitMaker.ecalCellLine(), EcalSelectiveReadoutValidation.EcalSelectiveReadoutValidation(), HLTMonBTagClient.efficiency(), edm::TestMixedSource.endJob(), LumiCalculator.endLuminosityBlock(), PFEnergyCalibration.energyEmHad(), RooCBExGaussShape.evaluate(), AlignmentMonitorGeneric.event(), FWEveViewManager.eventBegin(), FWEveViewManager.eventEnd(), edm::eventsetup.EventSetupRecord::get< fwliteeswriter::Handle >(), TFParams.f3deg(), EcalCondDBInterface.fetchDCSDataSet(), SimG4HcalValidation.fetchHits(), LMFLmrSubIOV.fetchIdSql(), EcalCondDBInterface.fetchRunIOV(), DAClusterizerInZ.fill(), FBaseSimEvent.fill(), PhiSymmetryCalibration_step2.fillHistos(), PhiSymmetryCalibration_step2_SM.fillHistos(), HcalTestHistoClass.fillHits(), FastL1GlobalAlgo.FillL1RegionsTP(), TopDecaySubset.fillListing(), TopInitSubset.fillOutput(), FastTimerServiceClient.fillPathSummaryPlots(), HcalRecHitsAnalyzer.fillRecHitsTmp(), HcalRecHitsValidation.fillRecHitsTmp(), cms::BHFilter.filter(), ProtonTaggerFilter.filter(), HSCParticleProducer.filter(), RPCRecHitFilter.filter(), PhotonMCTruthFinder.find(), DTCombinatorialExtendedPatternReco.findCompatibleHits(), reco.findMethod(), TopDecaySubset.findTops(), CSCXonStrip_MatchGatti.findXOnStrip(), sistrip::LinearFit.fit(), sistrip::MeanAndStdDev.fit(), TFParams.fitpj(), CSCFindPeakTime.fivePoleFitCharge(), fnc_gaussalpha(), fnc_gaussalpha1alpha2(), edm::ModuleRegistry.forAllModuleHolders(), edm::service::ELstatistics.formSummary(), cond::time.from_boost(), lumi.from_string(), HcalDbOmds.from_string(), cond::time.from_timeval(), FWCollectionSummaryModelCellRenderer.FWCollectionSummaryModelCellRenderer(), FWCollectionSummaryWidget.FWCollectionSummaryWidget(), HepMCValidationHelper.genMet(), edm::helper::CandMasterKeyReference.get(), edm::helper::AssociationIdenticalKeyReference.get(), get_4(), edm::service::ThreadSafeLogMessageLoggerScribe.getAparameter(), edm::service::MessageLoggerScribe.getAparameter(), HcalLaserEventFilter.GetCMSSWVersion(), TShapeAnalysis.getDateStart(), TShapeAnalysis.getDateStop(), LMFRunIOV.getDBInsertionTime(), edm::RootTree.getEntry(), globcontrol.getfunction(), L1TauAnalyzer.getGenObjects(), HSCParticleProducer.getHSCPSeedCollection(), WatcherStreamFileReader.getInputFile(), edm::JobReport::JobReportImpl.getInputFileForToken(), LMFLmrSubIOV.getIOVIDsLaterThan(), LMFDat.getKeyTypes(), PhiSymmetryCalibration.getKfactors(), EcalLaserDbService.getLaserCorrection(), fireworks.getLocalTime(), TouchableToHistory.getNavStory(), popcon::EcalLaser_weekly_Handler.getNewObjects(), SiStripPulseShape.getNormalizedValue(), edm::JobReport::JobReportImpl.getOutputFileForToken(), DTBufferTreeTrait< T >.getOutputValue(), LMFLmrSubIOV.getParameters(), DataReducer< T >.getReducedDataList(), PerformancePayloadFromBinnedTFormula.getResult(), PerformancePayloadFromTFormula.getResult(), LMFSeqDat.getSequenceStart(), LMFSeqDat.getSequenceStop(), PrimaryVertexAnalyzer4PU.getSimEvents(), PrimaryVertexAnalyzer.getSimPVs(), PrimaryVertexAnalyzer4PU.getSimTrkParameters(), LMFRunIOV.getSubRunEnd(), LMFRunIOV.getSubRunStart(), LMFLmrSubIOV.getTime(), fireworks.getTimeGMT(), FWPFTrackUtils.getTrack(), CSCDriftSim.getWireHit(), reco::GhostTrackPrediction.GhostTrackPrediction(), FWEveViewManager.globalEnergyScaleChanged(), CachingSeedCleanerByHitPosition.good(), CachingSeedCleanerBySharedInput.good(), FWEveViewManager.haveViewForBit(), HcalShapeIntegrator.HcalShapeIntegrator(), QualityCutsAnalyzer::histogram_element_t.histogram_element_t(), CSCMake2DRecHit.hitFromStripAndWire(), i2str(), edm::service.i2str(), module.ifelse(), gen::Cascade2Hadronizer.imposeProperTime(), gen::Pythia6Hadronizer.imposeProperTime(), TMatacq.init(), edm::EventSelector.init(), Thrust.init(), PerformancePayloadFromBinnedTFormula.initialize(), edm::DetSetVector< T >.insert(), HBHEHitMap.insert(), lumi::TRGWBM2DB.int2str(), lumi::TRGScalers2DB.int2str(), HcalPulseShape.integrate(), CastorPulseShapes::Shape.integrate(), LinearGridInterpolator3D.interpolate(), MatacqDataFormatter.interpretRawData(), ROOT::Math::Transform3DPJ.Inverse(), PerformancePayloadFromTable.isInPayload(), PerformancePayloadFromBinnedTFormula.isOk(), PerformancePayloadFromTFormula.isOk(), cond::BlobStreamingService.isVectorChar(), SimG4HcalValidation.jetAnalysis(), L1RPCConeDefinitionProducer.L1RPCConeDefinitionProducer(), LMFSeqDat.LMFSeqDat(), G4SimEvent.load(), FSimEvent.load(), EcalDeadChannelRecoveryNN< DetIdT >.load_file(), HcalDetDiagPedestalMonitor.LoadDataset(), HcalDetDiagLaserMonitor.LoadDataset(), HcalNumberingFromDDD.loadGeometry(), HcalDetDiagLEDMonitor.LoadReference(), HcalDetDiagPedestalMonitor.LoadReference(), HcalDetDiagLaserMonitor.LoadReference(), HLTPerformanceInfo.longestModuleCPUTime(), HLTPerformanceInfo.longestModuleCPUTimeName(), HLTPerformanceInfo.longestModuleTime(), HLTPerformanceInfo.longestModuleTimeName(), LookInStream_SeekTo(), LzmaDec_DecodeReal(), TFileDirectory.make(), edm::eventsetup::DataKey.makeCopyOfMemory(), FWRPZViewGeometry.makeShape(), gen::TauolappInterface.MatchedLHESpinUp(), PerformancePayloadFromTable.matches(), PrimaryVertexAnalyzer4PU.matchRecTracksToVertex(), DTTime2DriftParametrization.MB_DT_delta_x(), CSCRadialStripTopology.measurementError(), TkRadialStripTopology.measurementError(), MeasurementTrackerEventProducer.MeasurementTrackerEventProducer(), gen::Hydjet2Hadronizer.MidpointIntegrator2(), TFParams.mixShape(), Conv.mkbins(), FWEventItem.modelInfo(), module.negedge(), MuonSensitiveDetector.newHit(), FWEveViewManager.newItem(), pat::Muon.normChi2(), ora::NullTypeHandler.NullTypeHandler(), pat::Muon.numberOfValidHits(), SimG4HcalValidation.nxNAnalysis(), CaloSamples.offsetTime(), FWDetailViewManager.openDetailViewFor(), DCUTag.operator!=(), MonRunTag.operator!=(), RunTag.operator!=(), CaliTag.operator!=(), cscdqm::HWStandbyType.operator!=(), reco::parser::AnyMethodArgumentFixup.operator()(), reco::parser::AnyMethodArgument2VoidPtr.operator()(), Signal.operator()(), ROOT::Math::Transform3DPJ.operator()(), operator*(), ROOT::Math::Transform3DPJ.operator*(), VectorDoublet< Vector3D, Vector3D >.operator*=(), Vector2DBase< float, MeasurementTag >.operator*=(), Vector3DBase< float, MeasurementTag >.operator*=(), Basic2DVector< float >.operator*=(), Basic3DVector< long double >.operator*=(), Basic3DVector< align::Scalar >.operator*=(), Signal.operator,(), operator/(), VectorDoublet< Vector3D, Vector3D >.operator/=(), Vector2DBase< float, MeasurementTag >.operator/=(), Vector3DBase< float, MeasurementTag >.operator/=(), Basic2DVector< float >.operator/=(), Basic3DVector< long double >.operator/=(), Basic3DVector< align::Scalar >.operator/=(), operator<<(), edm::MessageSender.operator<<(), cscdqm::LogCout.operator<<(), edm::LogSystem.operator<<(), edm::LogAbsolute.operator<<(), bostream_iterator< T >.operator=(), edm::AssociationVector< KeyRefProd, CVal, KeyRef, SizeType, KeyReferenceHelper >.operator=(), ora::UniqueRef< T >.operator=(), ora::Ptr< T >.operator=(), cscdqm::FEDHistoDef.operator=(), cscdqm::DDUHistoDef.operator=(), cscdqm::CSCHistoDef.operator=(), edm::AssociationVector< KeyRefProd, CVal, KeyRef, SizeType, KeyReferenceHelper >.operator[](), Signal.operator||(), ext::basic_omemstream< Item_t, Traits_t, Allocator_t >.overflow(), cond::time.pack(), cond::persistency.parseTag(), Particle.Particle(), InnerDeltaPhi.phiRange(), edm::SerialTaskQueue.pickNextTask(), PixelUnpackingRegions.PixelUnpackingRegions(), DTPosNegType.pnCode(), DTPosNeg.pnCode(), DDStreamer.pos_read(), module.posedge(), edm::service::Timing.postEndJob(), edm.postIndexIntoFilePrintEventLists(), edm.postIndexIntoFilePrintEventsInLumis(), edm::service::Timing.postModule(), CSCChipSpeedCorrectionDBConditions.prefillDBChipSpeedCorrection(), fireworks.prepareCandidate(), EMShower.prepareSteps(), fireworks.prepareTrack(), PerformancePayloadFromBinnedTFormula.printFormula(), PerformancePayloadFromTFormula.printFormula(), PrimaryVertexAnalyzer4PU.printPVTrks(), PrimaryVertexAnalyzer4PU.printRecTrks(), PrimaryVertexAnalyzer.printSimTrks(), PrimaryVertexAnalyzer4PU.printSimTrks(), EcalSelectiveReadoutProducer.printSrFlags(), MultiVertexFitter.printWeights(), ora::PrimitiveMapping.process(), JetTracksAssociationDRVertex.produce(), JetTracksAssociationDRVertexAssigned.produce(), JetTracksAssociationDRCalo.produce(), JetVetoedTracksAssociationDRVertex.produce(), ISRGammaWeightProducer.produce(), ReducedESRecHitCollectionProducer.produce(), ParticleReplacerParticleGun.produce(), EcalDetIdToBeRecoveredProducer.produce(), InclusiveVertexFinder.produce(), edm::ProductFromFwdPtrProducer< T, H >.produce(), ReducedRecHitCollectionProducer.produce(), HLTCollectionProducer< T >.produce(), BSCTrigger.produce(), HcalHitSelection.produce(), EcalSimpleProducer.produce(), HcalForwardLibWriter.produce(), JetCrystalsAssociator.produce(), MatacqProducer.produce(), Strip1DMeasurementTransformator.projectionMatrix(), ora::Ptr< T >.Ptr(), edm::ProcessHistory.push_front(), edm::SerialTaskQueue.pushTask(), KfTrackProducerBase.putInEvt(), GsfTrackProducerBase.putInEvt(), TrackProducerWithSCAssociation.putInEvt(), CocoaToDDLMgr.pv(), PrimaryVertexMonitor.pvTracksPlots(), ClusterShapeTrajectoryFilter.qualityFilter(), TtFullLepKinSolver.quartic(), rand(), MuonResiduals5DOFFitter.readNtuple(), MuonResiduals6DOFFitter.readNtuple(), MuonResiduals6DOFrphiFitter.readNtuple(), VertexFitterManager.registerFitter(), HepMCValidationHelper.removeIsolatedLeptons(), L1GctGlobalHfSumAlgos.resetPipelines(), CastorSimpleRecAlgo.resetTimeSamples(), BtoCharmDecayVertexMerger.resolveBtoDchain(), edm::SerialTaskQueue.resume(), ror(), gen::PyquenHadronizer.rotateEvtPlane(), rxor(), CSCDigiValidator.sanitizeWireDigis(), TagProbeFitter.saveEfficiencyPlots(), HcalDetDiagLaserMonitor.SaveRaddamData(), HcalDetDiagNoiseMonitor.SaveRates(), HcalDetDiagLEDMonitor.SaveReference(), HcalDetDiagPedestalMonitor.SaveReference(), HcalDetDiagLaserMonitor.SaveReference(), FEDTrailer.set(), hitfit::Lepjets_Event.set_jet_types(), TFHeaderDescription.setBunchCrossing(), RunIOV.setByTime(), HLTPerformanceInfo::Module.setCPUTime(), CaloTower.setEcalTime(), TFHeaderDescription.setFedEventNumber(), TFHeaderDescription.setFedId(), TFHeaderDescription.setFedType(), reco::Muon.setGlobalTrack(), CaloTower.setHcalTime(), FWTableWidget.SetHeaderBackgroundColor(), FWTableWidget.SetHeaderForegroundColor(), RunDCSHVDat.setHV(), RunDCSHVDat.setHVNominal(), reco::CaloMuon.setInnerTrack(), reco::Muon.setInnerTrack(), FWTableWidget.SetLineSeparatorColor(), RunDCSLVDat.setLV(), RunDCSLVDat.setLVNominal(), RunDCSMagnetDat.setMagnetCurrent(), reco::Muon.setMuonTrack(), TFHeaderDescription.setNumberOfChannels(), TFHeaderDescription.setNumberOfSamples(), reco::Muon.setOuterTrack(), PFECALSuperClusterAlgo.setSatelliteThreshold(), RunDCSLVDat.setStatus(), RunDCSHVDat.setStatus(), pftools::CalibCompare.setTarget(), pftools::Exercises3.setTarget(), RunPTMTempDat.setTemperature(), BscG4Hit.setThetaAtEntry(), FP420G4Hit.setThetaAtEntry(), TotemG4Hit.setThetaAtEntry(), FiberG4Hit.setTime(), HFShowerG4Hit.setTime(), HLTPerformanceInfo::Module.setTime(), PCaloHit.setTime(), RunDCSLVDat.setTimeStatus(), RunDCSHVDat.setTimeStatus(), Tm.setToCurrentGMTime(), Tm.setToCurrentLocalTime(), Tm.setToMicrosTime(), CurrentG4Track.setTrack(), CoreSimTrack.setTrackId(), SubTaskSummaryStatus.Setup(), FWGeoTopNode.setupBuffMtx(), edm::AssociationVector< KeyRefProd, CVal, KeyRef, SizeType, KeyReferenceHelper >.setValue(), BscG4Hit.setVx(), FP420G4Hit.setVx(), TotemG4Hit.setVx(), BscG4Hit.setVy(), FP420G4Hit.setVy(), TotemG4Hit.setVy(), BscG4Hit.setVz(), FP420G4Hit.setVz(), TotemG4Hit.setVz(), BscG4Hit.setX(), FP420G4Hit.setX(), TotemG4Hit.setX(), BscG4Hit.setY(), FP420G4Hit.setY(), TotemG4Hit.setY(), BscG4Hit.setZ(), FP420G4Hit.setZ(), TotemG4Hit.setZ(), gen::Hydjet2Hadronizer.SimpsonIntegrator(), MatRepSparse< T, D1, D2, S, F >.sink(), DDStreamer.solids_read(), RKCurvilinearDistance< T, N >.sqr(), sqr(), edm::CPUTimer.stop(), MuonSensitiveDetector.storeVolumeAndTrack(), cscdqm.stringToNumber(), edm::service::ELstatistics.summaryForJobReport(), CSCAnalogSignal.superimpose(), PrimaryVertexAnalyzer4PU.supf(), ME.time_low(), HcalHitCorrection.timeBin(), CastorHitCorrection.timeBin(), cond.to_string(), FWCollectionSummaryWidget.toggleShowHide(), cscdqm.toString(), HLTPerformanceInfo.totalCPUTime(), HLTPerformanceInfo.totalPathCPUTime(), HLTPerformanceInfo.totalPathTime(), HLTPerformanceInfo.totalTime(), TPGCheck.TPGCheck(), TrackProducerFP420.trackFinderSophisticated(), MuonTrackAnalyzer.tracksAnalysis(), reco::JetTracksAssociation.tracksP4(), CosmicMuonTrajectoryBuilder.trajectories(), ShallowTree::TypedBranchConnector< T >.TypedBranchConnector(), edm::TypeWithDict.TypeWithDict(), ora::UniqueRef< T >.UniqueRef(), unit(), DummyVertexTrackUpdator< N >.update(), fwlite::RecordWriter.update(), CastorShowerLibraryMaker.update(), EcalSelectiveReadoutValidation.updateL1aRate(), PrimaryVertexMonitor.vertexPlots(), TrimmedVertexFinder.vertices(), writeABIOFileHeader(), writeABSRFFileHeader(), writeABTTFFileHeader(), FEConfigFgrParamDat.writeArrayDB(), FEConfigFgrGroupDat.writeArrayDB(), FEConfigWeightGroupDat.writeArrayDB(), FEConfigParamDat.writeArrayDB(), MonPedestalsDat.writeArrayDB(), MonMemTTConsistencyDat.writeArrayDB(), MonTestPulseDat.writeArrayDB(), MonTTConsistencyDat.writeArrayDB(), MonPNLed2Dat.writeArrayDB(), MonPNGreenDat.writeArrayDB(), MonPNMGPADat.writeArrayDB(), MonPNBlueDat.writeArrayDB(), MonPNRedDat.writeArrayDB(), MonPNIRedDat.writeArrayDB(), MonPNLed1Dat.writeArrayDB(), DCULVRVoltagesDat.writeArrayDB(), VirtualJetProducer.writeJets(), EcalDccWeightBuilder.writeWeightToRootFile(), and MatacqProducer.~MatacqProducer().

edmStreamStallGrapher.time = getTime(l)

Definition at line 57 of file edmStreamStallGrapher.py.

int edmStreamStallGrapher.trans = 0

Definition at line 61 of file edmStreamStallGrapher.py.

Referenced by DisplayGeom.analyze(), clone(), edm::Exception.codeToString(), SiStripGainFromData.ComputeChargeOverPath(), cond::Logger.createLogDBIfNonExist(), TestFunct.CreateMetaTable(), TGeoMgrFromDdd.createShape(), CrystalPad.CrystalPad(), TestFunct.DropItem(), CocoaDBMgr.GetAlignInfoFromOptO(), FWGeometry.getMatrix(), TestFunct.GetMetadata(), EcalHitMaker.getPads(), cond::Logger.logFailedOperationNow(), cond::Logger.logOperationNow(), svgfig.Ticks.orient_tickmark(), svgfig.Poly.Path(), DTGeometryBuilderFromDDD.plane(), DTGeometryParsFromDD.plane(), TestFunct.Read(), TestFunct.ReadAll(), TestFunct.ReadWithIOV(), svgfig.Path.SVG(), svgfig.Text.SVG(), svgfig.Dots.SVG(), svgfig.LineGlobal.SVG(), MuonEndcapFrameRotation.transformPoint(), DDEcalEndcapTrap.translate(), DDG4SolidConverter.trunctubs(), TestFunct.Write(), and TestFunct.WriteWithIOV().

list edmStreamStallGrapher.waitTime = None

Definition at line 87 of file edmStreamStallGrapher.py.