CMS 3D CMS Logo

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

Classes

class  FileDeleter
 

Functions

def cleanup_threshold
 
def daemon
 
def diskusage
 
def iterate
 
def lock
 
def parse_file_name
 

Variables

tuple deleter
 
tuple fake = not(len(sys.argv) > 1 and sys.argv[1] == "doit")
 
 log = logging
 
tuple re_files = re.compile(r"^run(?P<run>\d+)/run(?P<runf>\d+)_ls(?P<ls>\d+)_.+\.(dat|raw)+(\.deleted)*")
 
tuple sock = lock("fff_deleter")
 
dictionary thresholds
 
string top = "/fff.changeme/ramdisk"
 

Function Documentation

def fff_deletion.cleanup_threshold (   top,
  threshold,
  action,
  string 
)

Definition at line 51 of file fff_deletion.py.

References iterate(), and AlCaHLTBitMon_ParallelJobs.p.

Referenced by fff_deletion.FileDeleter.run().

51 
52 def cleanup_threshold(top, threshold, action, string):
53  st = os.statvfs(top)
54  total = st.f_blocks * st.f_frsize
55  used = total - (st.f_bavail * st.f_frsize)
56  threshold = used - float(total * threshold) / 100
57 
58  def p(x):
59  return float(x) * 100 / total
60 
61  log.info("Using %d (%.02f%%) of %d space, %d (%.02f%%) above %s threshold.",
62  used, p(used), total, threshold, p(threshold), string)
63 
64  if threshold > 0:
65  iterate(top, threshold, action)
66  log.info("Done cleaning up for %s threshold.", string)
67  else:
68  log.info("Threshold %s not reached, doing nothing.", string)
def cleanup_threshold
Definition: fff_deletion.py:51
def fff_deletion.daemon (   deleter,
  delay_seconds = 30 
)

Definition at line 152 of file fff_deletion.py.

153 def daemon(deleter, delay_seconds=30):
154  while True:
155  deleter.run()
156  time.sleep(delay_seconds)
def fff_deletion.diskusage (   top)

Definition at line 69 of file fff_deletion.py.

Referenced by fff_deletion.FileDeleter.run().

69 
70 def diskusage(top):
71  st = os.statvfs(top)
72  total = st.f_blocks * st.f_frsize
73  used = total - (st.f_bavail * st.f_frsize)
74  return float(used) * 100 / total
def fff_deletion.iterate (   top,
  stopSize,
  action 
)

Definition at line 22 of file fff_deletion.py.

References alignCSCRings.action, and parse_file_name().

Referenced by cleanup_threshold().

22 
23 def iterate(top, stopSize, action):
24  # entry format (path, size)
25  collected = []
26 
27  for root, dirs, files in os.walk(top, topdown=True):
28  for name in files:
29  fp = os.path.join(root, name)
30  rl = os.path.relpath(fp, top)
31 
32  sort_key = parse_file_name(rl)
33  if sort_key:
34  fsize = os.stat(fp).st_size
35  if fsize == 0:
36  continue
37 
38  sort_key = parse_file_name(rl)
39  collected.append((sort_key, fp, fsize, ))
40 
41  # for now just use simple sort
42  collected.sort(key=lambda x: x[0])
43 
44  # do the action
45  for sort_key, fp, fsize in collected:
46  if stopSize <= 0:
47  break
48 
49  action(fp)
50  stopSize = stopSize - fsize
def parse_file_name
Definition: fff_deletion.py:13
def fff_deletion.lock (   pname)

Definition at line 144 of file fff_deletion.py.

Referenced by evf::FastMonitoringService.accumulateFileSize(), cond::service::PoolDBOutputService.appendSinceTime(), cscdqm::Collection.book(), cscdqm::EventProcessor.calcEMUFractionHisto(), ecaldqm.checkElectronicsMap(), ecaldqm.checkGeometry(), ecaldqm.checkTopology(), ecaldqm.checkTrigTowerMap(), cond::service::PoolDBOutputService.closeIOV(), StorageAccount.counter(), cond::service::PoolDBOutputService.createNewIOV(), cond::XMLAuthenticationService::XMLAuthenticationService.credentials(), evf::FastMonitoringService.dowork(), CSCMonitorObject.Fill(), CSCMonitorObject.GetBinContent(), CSCMonitorObject.GetBinError(), CSCMonitorObject.GetEntries(), evf::FastMonitoringService.getEventsProcessedForLumi(), CSCMonitorObject.GetMaximumBin(), cond::service::PoolDBOutputService.initDB(), edm::JobReport.inputFileClosed(), cond::service::PoolDBOutputService.lookUpRecord(), BeamSpotWorkflow.main(), DQMNet.onPeerConnect(), DQMNet.onPeerData(), evf::FastMonitoringService.postBeginJob(), evf::FastMonitoringService.preGlobalBeginLumi(), evf::FastMonitoringService.preGlobalEndLumi(), evf::FastMonitoringService.preModuleBeginJob(), evf::FastMonitoringService.prePathEvent(), evf::FastMonitoringService.preStreamBeginLumi(), evf::FastMonitoringService.preStreamEndLumi(), cscdqm::Dispatcher.processStandby(), edm::JobReport.reportAnalysisFile(), edm::JobReport.reportError(), evf::FastMonitoringService.reportEventsThisLumiInSource(), edm::JobReport.reportFallbackAttempt(), edm::JobReport.reportRandomStateFile(), edm::JobReport.reportSkippedEvent(), edm::JobReport.reportSkippedFile(), CSCMonitorObject.SetAxisRange(), CSCMonitorObject.setAxisTitle(), CSCMonitorObject.SetBinContent(), CSCMonitorObject.SetBinError(), ecaldqm.setElectronicsMap(), CSCMonitorObject.SetEntries(), ecaldqm.setGeometry(), CSCMonitorObject.SetMaximum(), CSCMonitorObject.SetNormFactor(), ecaldqm.setTopology(), ecaldqm.setTrigTowerMap(), StorageAccount::Stamp.Stamp(), cscdqm::EventProcessor.standbyEfficiencyHistos(), edm::ZombieKillerService.startThread(), evf::FastMonitoringService.stoppedLookingForFile(), cond::service::PoolDBOutputService.tagInfo(), StorageAccount::Stamp.tick(), cscdqm::EventProcessor.updateEfficiencyHistos(), cscdqm::EventProcessorMutex.updateFractionAndEfficiencyHistos(), cscdqm::Dispatcher.updateFractionAndEfficiencyHistos(), cscdqm::EventProcessor.updateFractionHistos(), cond::service::PoolDBOutputService.writeOne(), and cscdqm::EventProcessor.writeShifterHistograms().

145 def lock(pname):
146  sock = socket.socket(socket.AF_UNIX, socket.SOCK_DGRAM)
147  try:
148  sock.bind('\0' + pname)
149  return sock
150  except socket.error:
151  return None
def fff_deletion.parse_file_name (   rl)

Definition at line 13 of file fff_deletion.py.

Referenced by iterate().

13 
14 def parse_file_name(rl):
15  m = re_files.match(rl)
16  if not m:
17  return None
18 
19  d = m.groupdict()
20  sort_key = (int(d["run"]), int(d["runf"]), int(d["ls"]), )
21  return sort_key
def parse_file_name
Definition: fff_deletion.py:13

Variable Documentation

tuple fff_deletion.deleter
Initial value:
2  top = top,
3  thresholds = thresholds,
4  # put "41XXXXXXXXX@mail2sms.cern.ch" to send the sms
5  email_to = ["dmitrijus.bugelskis@cern.ch", ],
6  fake = fake,
7  )

Definition at line 185 of file fff_deletion.py.

Referenced by QcdLowPtDQM.~QcdLowPtDQM().

tuple fff_deletion.fake = not(len(sys.argv) > 1 and sys.argv[1] == "doit")

Definition at line 183 of file fff_deletion.py.

Referenced by TopDiLeptonDQM.analyze(), and SymmetryFit.symmetryChi2().

fff_deletion.log = logging

Definition at line 10 of file fff_deletion.py.

Referenced by WeakEffectsWeightProducer.alphaQED(), FSRWeightProducer.alphaRatio(), DQMHOAlCaRecoStream.analyze(), evf::ExceptionGenerator.analyze(), HcalNoiseMonitor.analyze(), ESTimingTask.analyze(), MCPhotonAnalyzer.analyze(), DQMSourceExample.analyze(), TrackerHitAnalyzer.analyze(), ZMuMuEfficiency.analyze(), ValidationMisalignedTracker.analyze(), L1CondDBIOVWriter.analyze(), EcalPreshowerSimHitsValidation.analyze(), L1O2OTestAnalyzer.analyze(), EcalSimHitsValidation.analyze(), EcalRecHitsValidation.analyze(), EcalDigisValidation.analyze(), Rivet::CMS_EWK_11_021.analyze(), PrimaryVertexAnalyzer4PU.analyzeVertexCollection(), PrimaryVertexAnalyzer4PU.analyzeVertexCollectionTP(), PhotonFix.asinh(), TopDiLeptonDQM.beginJob(), DAClusterizerInZ.beta0(), DAClusterizerInZ_vect.beta0(), RapReweightUserHook.biasSelectionBy(), PtHatRapReweightUserHook.biasSelectionBy(), BremsstrahlungSimulator.brem(), FWPFEcalRecHitLegoProxyBuilder.build(), CSCSectorReceiverMiniLUT.calcGlobalEtaMEMini(), LRHelpFunctions.calcLRval(), EnergyResolutionVsLumi.calcmuTot(), ClusterShapeAlgo.Calculate_Covariances(), PFEGammaAlgo.calculate_ele_mva(), ClusterShapeAlgo.Calculate_EnergyDepTopology(), PositionCalc.Calculate_Location(), TBPositionCalc.CalculateCMSPos(), calculateEta(), MuonNavigationSchool.calculateEta(), DirectTrackerNavigation.calculateEta(), ConversionLikelihoodCalculator.calculateLikelihood(), EcalClusterToolsT< noZS >.cluster2ndMoments(), MultipleScatteringSimulator.compute(), PairProductionSimulator.compute(), EnergyLossSimulator.compute(), BremsstrahlungSimulator.compute(), NuclearInteractionSimulator.compute(), TMarkov.computeChain(), PileupJetIdAlgo.computeCutIDflag(), DeDxDiscriminatorProducer.ComputeDiscriminator(), HDRShower.computeShower(), EcalSelectiveReadoutValidation.configFirWeights(), DDHCalBarrelAlgo.constructMidLayer(), DDHCalBarrelAlgo.constructSideLayer(), EGEnergyCorrector.CorrectedEnergyWithError(), HFRecoEcalCandidateAlgo.correctEPosition(), MuonMETAlgo.correctMETforMuon(), VVIObjDetails.cosint(), sistripvvi::VVIObjDetails.cosint(), PFClusterShapeAlgo.covariances(), EcalClusterToolsT< noZS >.covariances(), cond::RelationalAuthenticationService::RelationalAuthenticationService.credentials(), EvolutionECAL.DegradationMeanEM50GeV(), HcalTimeSlew.delay(), CastorTimeSlew.delay(), SimpleSecondaryVertexComputer.discriminator(), JetBProbabilityComputer.discriminator(), PF_PU_AssoMapAlgos.dR(), ChargeDrifterFP420.drift(), DAClusterizerInZ.dump(), DAClusterizerInZ_vect.dump(), MuScleFit.duringFastLoop(), Pi0FixedMassWindowCalibration.duringLoop(), ECALPositionCalculator.ecalEta(), HICaloUtil.EcalEta(), ContainmentCorrectionAnalyzer.ecalEta(), EgammaSuperClusters.ecalEta(), EgammaObjects.ecalEta(), EcalUncalibRecHitRecChi2Algo< C >.EcalUncalibRecHitRecChi2Algo(), Conv.elec(), EMShower.EMShower(), CalorimetryManager.EMShowerSimulation(), CaloTowersCreationAlgo.emShwrLogWeightPos(), TtSemiLepJetCombMVATrainer.endJob(), GsfElectronDataAnalyzer.endJob(), GsfElectronMCFakeAnalyzer.endJob(), GsfElectronFakeAnalyzer.endJob(), GsfElectronMCAnalyzer.endJob(), npstat::EquidistantInLogSpace.EquidistantInLogSpace(), hf_egamma.eSeLCorrected(), kinem.eta(), Geom::OnePiRange< T >.eta(), reco::GhostTrackPrediction.eta(), RawParticle.eta(), cscdqm::Detector.Eta(), fastmath.etaphi(), etaRel(), PhotonsWithConversionsAnalyzer.etaTransformation(), SimpleConvertedPhotonAnalyzer.etaTransformation(), MCElectronAnalyzer.etaTransformation(), MCPhotonAnalyzer.etaTransformation(), MCPizeroAnalyzer.etaTransformation(), SimplePhotonAnalyzer.etaTransformation(), TkConvValidator.etaTransformation(), PhotonValidator.etaTransformation(), ConversionProducer.etaTransformation(), VariablePower.eval(), ESRecHitAnalyticAlgo.EvalAmplitude(), ESRecHitSimAlgo.evalAmplitude(), PFPhotonAlgo.EvaluateLCorrMVA(), DDHCalFibreBundle.execute(), VVIObjDetails.expint(), sistripvvi::VVIObjDetails.expint(), sistripvvi::VVIObjDetails.f1(), sistripvvi::VVIObjDetails.f2(), FFTGenericScaleCalculator.f_safeLog(), fcnbg(), fcnsg(), HcalTestAnalysis.fill(), SimG4HcalValidation.fill(), HcalTB06Analysis.fillBuffer(), HcalTB04Analysis.fillBuffer(), SoftPFElectronTagInfoProducer.fillElecProperties(), DaqFakeReader.fillFEDs(), TrackerHitProducer.fillG4MC(), SoftPFMuonTagInfoProducer.fillMuonProperties(), PrimaryVertexAnalyzer4PU.fillTrackHistos(), EnergyScaleAnalyzer.fillTree(), ZeePlots.fillZMCInfo(), PythiaFilter.filter(), DJpsiFilter.filter(), ElectronMcSignalPostValidator.finalize(), ElectronMcFakePostValidator.finalize(), TFParams.fitpj(), GflashHadronShowerProfile.fLnE1(), GflashHadronShowerProfile.fTanh(), FWExpressionValidator.FWExpressionValidator(), FWLegoCandidate.FWLegoCandidate(), GammaFunctionGenerator.gammaFrac(), GammaFunctionGenerator.gammaInt(), GammaLn(), Gauss3DFunc(), PairProductionSimulator.gbteth(), BremsstrahlungSimulator.gbteth(), MuonBremsstrahlungSimulator.gbteth(), GaussianTailNoiseGenerator.generate_gaussian_tail(), EcalTestDevDB.generateEcalLaserAPDPNRatios(), CSCGasCollisions.generateEnergyLoss(), BaseNumericalRandomGenerator.generateExp(), TrackerMap.getAutomaticRange(), ECalSD.getBirkL3(), TrackerMap.getcolor(), reco::PFCluster.getDepthCorrection(), DetIdAssociator.getDetIdsCloseToAPoint(), ZdcSD.getEnergyDeposit(), CastorSD.getEnergyDeposit(), EcalClusterToolsT< noZS >.getEnergyDepTopology(), HcalNumberingFromDDD.getEta(), TopologyWorker.getetaphi(), IsolatedPixelTrackCandidateProducer.GetEtaPhiAtEcal(), PythiaFilterIsolatedTrack.GetEtaPhiAtEcal(), HCALResponse.getHCALEnergyResponse(), EcalTrivialConditionRetriever.getIntercalibConstantsFromConfiguration(), npstat::GridAxis.getInterval(), CastorShowerLibraryMaker.GetKinematics(), HcalTB06BeamSD.getNames(), MaterialBudgetHcalHistos.getNames(), HCalSD.getNames(), popcon::EcalLaser_weekly_Linearization_Check.getNewObjects(), GflashHadronShowerProfile.getNumberOfSpots(), CastorShowerLibrary.getShowerHits(), HcalTB02HcalNumberingScheme.getUnitID(), EcalClusterLocalContCorrection.getValue(), EcalBasicClusterLocalContCorrection.getValue(), EcalClusterCrackCorrection.getValue(), JetCharge.getWeight(), HFGflash.gfParameterization(), GflashHadronShowerProfile.hadronicParameterization(), HCalSD.HCalSD(), HcalTB06BeamSD.HcalTB06BeamSD(), HDShower.HDShower(), HcalHF_S9S1algorithm.HFSetFlagFromS9S1(), HFShower.HFShower(), gen::Cascade2Hadronizer.imposeProperTime(), gen::Pythia6Hadronizer.imposeProperTime(), cond::XMLAuthenticationService::XMLAuthenticationService.initialize(), npstat::GridAxis.initialize(), ParticlePropagator.initProperDecayTime(), reco::TrackProbabilityTagInfo.jetProbability(), JetProbabilityComputer.jetProbability(), JetBProbabilityComputer.jetProbability(), EMECALShowerParametrization.k4(), LandauFP420.LandauFP420(), CSCTFPtMethods.Likelihood(), likelihood(), CSCTFPtMethods.Likelihood2(), CSCTFPtMethods.Likelihood2011(), CSCTFPtMethods.Likelihood2_2011(), npstat::GridAxis.linearInterval(), IncompleteGammaComplement.ln(), GaussianSumUtilities1D.lnPdf(), CaloTPGTranscoderULUT.loadHCALCompress(), GflashAntiProtonShowerProfile.loadParameters(), GflashKaonMinusShowerProfile.loadParameters(), GflashKaonPlusShowerProfile.loadParameters(), GflashPiKShowerProfile.loadParameters(), GflashProtonShowerProfile.loadParameters(), EcalClusterLocal.localCoordsEB(), EcalClusterLocal.localCoordsEE(), EcalClusterToolsT< noZS >.localCovariances(), fit::Likelihood< Sample, PDF, Yield >.log(), fit::Likelihood< Sample, PDF, NoExtendedLikelihood >.log(), CSCCrossGap.logGamma(), fit::Likelihood< Sample, PDF, Yield >.logNFactorial(), HFClusterAlgo.makeCluster(), FFTEtaLogPtConeRadiusMapper< MyJet, Adjustable >.map(), FFTGenericScaleCalculator.mapFFTJet(), L2AbsScaleCalculator.mapFFTJet(), EMECALShowerParametrization.meanLnAlphaHom(), EMECALShowerParametrization.meanLnAlphaSam(), EMECALShowerParametrization.meanLnTHom(), EMECALShowerParametrization.meanLnTSam(), GflashHadronShowerProfile.medianLateralArm(), MuonResidualsFitter_compute_log_convolution(), MuonResidualsFitter_logGaussPowerTails(), MuonResidualsFitter_logPowerLawTails(), MuonResidualsFitter_logPureGaussian(), MuonResidualsFitter_logPureGaussian2D(), MuonResidualsFitter_logROOTVoigt(), SoftElectronMVAEstimator.mva(), AntiElectronIDMVA5GBR.MVAValue(), L1CaloHcalScaleConfigOnlineProd.newObject(), EMECALShowerParametrization.nSpotsHom(), oldComputeBetheBloch(), oldComputeElectrons(), ESRecHitSimAlgo.oldEvalAmplitude(), oldMUcompute(), funct::LogStruct< T >.operator()(), TtDecayChannelSelector.operator()(), fftjetcms::EtaAndPtDependentPeakSelector.operator()(), reco::parser::log_f.operator()(), fit::HistoPoissonLikelihoodRatio< T >.operator()(), TtHadLRSignalSelObservables.operator()(), FcnBeamSpotFitPV.operator()(), TtSemiLRSignalSelObservables.operator()(), BSpdfsFcn.operator()(), fftjetcms::EtaAndPtLookupPeakSelector.operator()(), SimG4HcalHitCluster.operator+=(), EMECALShowerParametrization.p3(), logintpack.pack8log(), logintpack.pack8logCeil(), SiPixelRecHitQuality::Packing.Packing(), GflashEMShowerProfile.parameterization(), reco::PFCandidateEGammaExtra.PFCandidateEGammaExtra(), reco::PFCandidateElectronExtra.PFCandidateElectronExtra(), PFPhotonClusters.PFCrystalCoor(), PFSCEnergyCalibration.PFSCEnergyCalibration(), SiPixelTemplateSplit.PixelTempSplit(), PlotOccupancyMap(), PlotOccupancyMapPhase2(), JetPartonMatching.print(), TKinFitter.print(), TtSemiLeptonicEvent.print(), TtFullLeptonicEvent.print(), TtFullHadronicEvent.print(), TopGenEvent.print(), EcalSelectiveReadoutValidation.printAvailableHists(), TKinFitter.printMatrix(), l1t::Stage2TowerCompressAlgorithmFirmwareImp1.processEvent(), HcalBeamMonitor.processEvent(), cond::XMLAuthenticationService::XMLAuthenticationService.processFile(), QGTagger.produce(), edm::FlatRandomOneOverPtGunProducer.produce(), CastorFastClusterProducer.produce(), CastorFastTowerProducer.produce(), DeltaBetaWeights.produce(), MuonSimHitProducer.produce(), EcalTrivialConditionRetriever.produceEcalLaserAPDPNRatios(), ecaldqm::RawDataClient.producePlots(), RPCpg.rate(), PixelCPEBase.rawQualityWord(), SoftLepton.relativeEta(), cond::SQLMonitoringService.report(), cond::SQLMonitoringService.reportToOutputStream(), EvolutionECAL.ResolutionConstantTermEM50GeV(), ElectronLikelihood.resultLog(), EcalClusterToolsT< noZS >.roundnessSelectedBarrelRecHits(), RecoTracktoTP.s_eta(), TPtoRecoTrack.s_eta(), LandauFP420.SampleFluctuations(), TrackerMap.save(), TrackerMap.save_as_fectrackermap(), TrackerMap.save_as_fedtrackermap(), TrackerMap.save_as_HVtrackermap(), TrackerMap.save_as_psutrackermap(), BSFitter.scanPDF(), EcalClusterToolsT< noZS >.scLocalCovariances(), HDRShower.setFuncParam(), PFElectronAlgo.SetIDOutputs(), SiPixelRecHitQuality::Packing.setProbabilityQ(), SiPixelRecHitQuality::Packing.setProbabilityXY(), HBHEPulseShapeFlagSetter.SetPulseShapeFlags(), GaussianTail.shoot(), SiG4UniversalFluctuation.SiG4UniversalFluctuation(), WeakEffectsWeightProducer.sigma0_qqbarll(), cscdqm::Utility.SignificanceLevelHigh(), cscdqm::Utility.SignificanceLevelLow(), RPCSimParam.simulate(), GflashShowino.simulateFirstInteractionPoint(), VVIObjDetails.sincosint(), sistripvvi::VVIObjDetails.sincosint(), smearFunctionBase.smearEta(), HepMCValidationHelper.sortByRapidity(), PrimaryVertexAnalyzer4PU.supf(), TBposition(), hitfit.theta_to_eta(), MuonNavigableLayer.trackingRange(), muon.trackProbability(), TtFullHadSignalSel.TtFullHadSignalSel(), HcalNumberingFromDDD.unitID(), PrintGeomMatInfo.update(), PrintGeomInfoAction.update(), EcalSimHitsValidProducer.update(), TrackingVerboseAction.update(), HcalTestAnalysis.update(), HcalTB02Analysis.update(), DoCastorAnalysis.update(), ZdcTestAnalysis.update(), CastorTestAnalysis.update(), FP420Test.update(), BscTest.update(), FWPFLegoRecHit.updateScale(), IncompleteGammaComplement.value(), cond::XMLAuthenticationService::XMLAuthenticationService.verifyFileName(), VVIObj.VVIObj(), sistripvvi::VVIObj.VVIObj(), kinem.y(), and EMECALShowerParametrization.z1().

tuple fff_deletion.re_files = re.compile(r"^run(?P<run>\d+)/run(?P<runf>\d+)_ls(?P<ls>\d+)_.+\.(dat|raw)+(\.deleted)*")

Definition at line 12 of file fff_deletion.py.

tuple fff_deletion.sock = lock("fff_deleter")

Definition at line 167 of file fff_deletion.py.

Referenced by edm::storage::StatisticsSenderService.filePreCloseEvent().

dictionary fff_deletion.thresholds
Initial value:
1 = {
2  'delete': 80,
3  'rename': 60,
4  'email': 90,
5  }

Definition at line 178 of file fff_deletion.py.

Referenced by InitialClusteringStepBase._algoName(), muonisolation::NominalEfficiencyThresholds.add(), Basic2DGenericPFlowClusterizer.Basic2DGenericPFlowClusterizer(), Basic2DGenericTopoClusterizer.buildTopoCluster(), muonisolation::Cuts.Cuts(), muonisolation::NominalEfficiencyThresholds.dump(), LocalMaximumSeedFinder.LocalMaximumSeedFinder(), L1JetEtScaleOnlineProd.newObject(), L1HtMissScaleOnlineProd.newObject(), L1HfRingEtScaleOnlineProd.newObject(), operator<<(), PFlow2DClusterizerWithTime.PFlow2DClusterizerWithTime(), ESZeroSuppressionProducer.produce(), SpikeAndDoubleSpikeCleaner.SpikeAndDoubleSpikeCleaner(), SiStripFedZeroSuppression.suppress(), and muonisolation::NominalEfficiencyThresholds.thresholdValueForEfficiency().

string fff_deletion.top = "/fff.changeme/ramdisk"

Definition at line 177 of file fff_deletion.py.

Referenced by EcalPreshowerGeometry.alignmentTransformIndexLocal(), VpspScanAlgorithm.analyse(), DTChamberEfficiencyTask.analyze(), TTbar_Kinematics.analyze(), L1RCTElectronIsolationCard.calcElectronCandidates(), HEPTopTagger.check_cos_theta(), TopDecaySubset.checkShowerModel(), TopDecaySubset.checkWBosons(), CmsShowCommonPopup.CmsShowCommonPopup(), TGeoFromDddService.createManager(), SummaryGeneratorReadoutView.fill(), SummaryGeneratorControlView.fill(), get_transform(), GEMSimpleModel.getSimHitBx(), HTLogicalMapEntry.HTLogicalMapEntry(), TtFullHadHypothesis.hypo(), FWCompactVerticalLayout.Layout(), KinematicTree.motherParticle(), FWLayoutBuilder.nextHints(), TtDecayChannelSelector.operator()(), TopProjectorDeltaROverlap< Top, Bottom >.operator()(), FWTGeoRecoGeometryESProducer.produce(), TGeoMgrFromDdd.produce(), MEEEGeom.quadrant(), edm::service::MessageLogger.unEstablishModule(), FWConfigurationManager.writeToFile(), and edm::helper::IndexRangeAssociation::FastFiller.~FastFiller().