#include <Event.h>
Public Types | |
typedef unsigned long | CacheIdentifier_t |
typedef std::vector< std::pair < edm::propagate_const < std::unique_ptr< WrapperBase > >, BranchDescription const * > > | ProductPtrVec |
Public Member Functions | |
CacheIdentifier_t | cacheIdentifier () const |
Event (EventPrincipal const &ep, ModuleDescription const &md, ModuleCallingContext const *) | |
EventAuxiliary const & | eventAuxiliary () const |
EventSelectionIDVector const & | eventSelectionIDs () const |
template<typename ELEMENT > | |
void | fillView_ (BasicHandle &bh, Handle< View< ELEMENT > > &result) const |
template<typename PROD > | |
bool | get (ProductID const &oid, Handle< PROD > &result) const |
template<typename ELEMENT > | |
bool | get (ProductID const &oid, Handle< View< ELEMENT > > &result) const |
void | getAllProvenance (std::vector< Provenance const * > &provenances) const |
template<> | |
bool | getByLabel (std::string const &label, std::string const &productInstanceName, Handle< GenericObject > &result) const |
Specialize the getByLabel method to work with a Handle<GenericObject> More... | |
template<> | |
bool | getByLabel (edm::InputTag const &tag, Handle< GenericObject > &result) const |
template<> | |
bool | getByLabel (std::string const &label, std::string const &productInstanceName, Handle< GenericObject > &result) const |
Specialize the Event's getByLabel method to work with a Handle<GenericObject> More... | |
template<> | |
bool | getByLabel (edm::InputTag const &tag, Handle< GenericObject > &result) const |
template<typename PROD > | |
bool | getByLabel (InputTag const &tag, Handle< PROD > &result) const |
template<typename PROD > | |
bool | getByLabel (std::string const &label, Handle< PROD > &result) const |
template<typename PROD > | |
bool | getByLabel (std::string const &label, std::string const &productInstanceName, Handle< PROD > &result) const |
template<typename ELEMENT > | |
bool | getByLabel (std::string const &label, Handle< View< ELEMENT > > &result) const |
template<typename ELEMENT > | |
bool | getByLabel (std::string const &label, std::string const &productInstanceName, Handle< View< ELEMENT > > &result) const |
template<typename ELEMENT > | |
bool | getByLabel (InputTag const &tag, Handle< View< ELEMENT > > &result) const |
template<typename PROD > | |
bool | getByToken (EDGetToken token, Handle< PROD > &result) const |
template<typename PROD > | |
bool | getByToken (EDGetTokenT< PROD > token, Handle< PROD > &result) const |
template<typename ELEMENT > | |
bool | getByToken (EDGetToken token, Handle< View< ELEMENT >> &result) const |
template<typename ELEMENT > | |
bool | getByToken (EDGetTokenT< View< ELEMENT >> token, Handle< View< ELEMENT >> &result) const |
LuminosityBlock const & | getLuminosityBlock () const |
template<typename PROD > | |
void | getManyByType (std::vector< Handle< PROD > > &results) const |
bool | getProcessParameterSet (std::string const &processName, ParameterSet &ps) const |
Provenance | getProvenance (BranchID const &theID) const |
Provenance | getProvenance (ProductID const &theID) const |
template<typename PROD > | |
RefProd< PROD > | getRefBeforePut () |
template<typename PROD > | |
RefProd< PROD > | getRefBeforePut (std::string const &productInstanceName) |
Run const & | getRun () const |
void | labelsForToken (EDGetToken const &iToken, ProductLabels &oLabels) const |
ModuleCallingContext const * | moduleCallingContext () const |
virtual ProcessHistory const & | processHistory () const |
ProcessHistoryID const & | processHistoryID () const |
EDProductGetter const & | productGetter () const |
template<typename PROD > | |
OrphanHandle< PROD > | put (std::auto_ptr< PROD > product) |
Put a new product. More... | |
template<typename PROD > | |
OrphanHandle< PROD > | put (std::unique_ptr< PROD > product) |
template<typename PROD > | |
OrphanHandle< PROD > | put (std::auto_ptr< PROD > product, std::string const &productInstanceName) |
Put a new product with a 'product instance name'. More... | |
template<typename PROD > | |
OrphanHandle< PROD > | put (std::unique_ptr< PROD > product, std::string const &productInstanceName) |
RunNumber_t | run () const |
void | setConsumer (EDConsumerBase const *iConsumer) |
void | setSharedResourcesAcquirer (SharedResourcesAcquirer *iResourceAcquirer) |
size_t | size () const |
StreamID | streamID () const |
virtual edm::TriggerNames const & | triggerNames (edm::TriggerResults const &triggerResults) const |
virtual TriggerResultsByName | triggerResultsByName (std::string const &process) const |
virtual | ~Event () |
Public Member Functions inherited from edm::EventBase | |
int | bunchCrossing () const |
EventBase () | |
edm::EventAuxiliary::ExperimentType | experimentType () const |
template<typename T > | |
bool | get (ProductID const &, Handle< T > &) const |
template<typename T > | |
bool | getByLabel (InputTag const &, Handle< T > &) const |
template<> | |
bool | getByLabel (edm::InputTag const &tag, Handle< FWGenericObject > &result) const |
Specialize the getByLabel method to work with a Handle<FWGenericObject> More... | |
edm::EventID | id () const |
bool | isRealData () const |
edm::LuminosityBlockNumber_t | luminosityBlock () const |
int | orbitNumber () const |
edm::Timestamp | time () const |
virtual | ~EventBase () |
Private Types | |
typedef std::set< BranchID > | BranchIDSet |
Private Member Functions | |
void | addToGotBranchIDs (Provenance const &prov) const |
void | commit_ (std::vector< BranchID > *previousParentage=0, ParentageID *previousParentageId=0) |
void | commit_aux (ProductPtrVec &products, bool record_parents, std::vector< BranchID > *previousParentage=0, ParentageID *previousParentageId=0) |
EventPrincipal const & | eventPrincipal () const |
virtual BasicHandle | getByLabelImpl (std::type_info const &iWrapperType, std::type_info const &iProductType, InputTag const &iTag) const |
BasicHandle | getByProductID_ (ProductID const &oid) const |
virtual BasicHandle | getImpl (std::type_info const &iProductType, ProductID const &pid) const |
ProductID | makeProductID (BranchDescription const &desc) const |
ProductPtrVec & | putProducts () |
ProductPtrVec const & | putProducts () const |
ProductPtrVec & | putProductsWithoutParents () |
ProductPtrVec const & | putProductsWithoutParents () const |
Private Attributes | |
EventAuxiliary const & | aux_ |
BranchIDSet | gotBranchIDs_ |
std::vector< std::shared_ptr < ViewBase > > | gotViews_ |
std::shared_ptr < LuminosityBlock const > const | luminosityBlock_ |
ModuleCallingContext const * | moduleCallingContext_ |
PrincipalGetAdapter | provRecorder_ |
ProductPtrVec | putProducts_ |
ProductPtrVec | putProductsWithoutParents_ |
StreamID | streamID_ |
Static Private Attributes | |
static const std::string | emptyString_ |
Friends | |
class | ::testEventGetRefBeforePut |
class | InputSource |
class | ProducerBase |
class | ProducerSourceBase |
class | RawInputSource |
template<typename T > | |
class | stream::ProducingModuleAdaptorBase |
Additional Inherited Members | |
Static Protected Member Functions inherited from edm::EventBase | |
static TriggerNames const * | triggerNames_ (edm::TriggerResults const &triggerResults) |
|
private |
typedef unsigned long edm::Event::CacheIdentifier_t |
If you are caching data from the Event, you should also keep this number. If this number changes then you know that the data you have cached is invalid. The value of '0' will never be returned so you can use that to denote that you have not yet checked the value.
typedef std::vector<std::pair<edm::propagate_const<std::unique_ptr<WrapperBase> >, BranchDescription const*> > edm::Event::ProductPtrVec |
Event::Event | ( | EventPrincipal const & | ep, |
ModuleDescription const & | md, | ||
ModuleCallingContext const * | moduleCallingContext | ||
) |
Definition at line 17 of file Event.cc.
|
private |
Definition at line 182 of file Event.cc.
References edm::Provenance::branchID(), and gotBranchIDs_.
Referenced by fillView_(), get(), getByLabel(), getByLabelImpl(), getByToken(), getImpl(), and getManyByType().
Event::CacheIdentifier_t Event::cacheIdentifier | ( | ) | const |
Definition at line 32 of file Event.cc.
References edm::Principal::cacheIdentifier(), and eventPrincipal().
Referenced by Filter::accept(), Selection< C, Selector, StoreContainer >::accept(), Selection< C, Selector, StoreContainer >::acceptMap(), MuonDetLayerMeasurements::checkCSCRecHits(), MuonDetLayerMeasurements::checkDTRecHits(), MuonDetLayerMeasurements::checkGEMRecHits(), MuonDetLayerMeasurements::checkME0RecHits(), MuonDetLayerMeasurements::checkRPCRecHits(), muonisolation::CandViewExtractor::initEvent(), CachingVariable::notSeenThisEventAlready(), and VariableComputer::notSeenThisEventAlready().
|
private |
Definition at line 112 of file Event.cc.
References commit_aux(), putProducts(), and putProductsWithoutParents().
Referenced by edm::stream::ProducingModuleAdaptorBase< EDProducerBase >::commit(), and edm::ProducerSourceBase::readEvent_().
|
private |
Definition at line 118 of file Event.cc.
References assert(), eventPrincipal(), edm::get_underlying_safe(), gotBranchIDs_, eostools::move(), and groupFilesInBlocks::temp.
Referenced by commit_().
|
inlinevirtual |
Implements edm::EventBase.
Definition at line 77 of file Event.h.
References aux_.
Referenced by LaserTask::_process(), evf::EvFRecordUnpacker::analyze(), BxTiming::analyze(), ZeePlots::analyze(), WenuPlots::analyze(), L1TriggerJSONMonitoring::analyze(), PrimaryVertexValidation::analyze(), TriggerJSONMonitoring::analyze(), TrackerDpgAnalysis::analyze(), SingleTopTChannelLepton_miniAOD::MonitorEnsemble::fill(), TopSingleLepton_miniAOD::MonitorEnsemble::fill(), HLTOfflineDQMTopDiLepton::MonitorDiLepton::fill(), TopSingleLepton::MonitorEnsemble::fill(), SingleTopTChannelLepton::MonitorEnsemble::fill(), TopDiLeptonOffline::MonitorEnsemble::fill(), DetStatus::filter(), HSCPHLTFilter::filter(), CSCSkim::filter(), ZeeCandidateFilter::filter(), HSCPTreeBuilder::filter(), CSCTriggerPrimitivesProducer::produce(), L1Analysis::L1AnalysisSimulation::Set(), and L1Analysis::L1AnalysisEvent::Set().
|
private |
Definition at line 50 of file Event.cc.
References compareJSON::const, edm::PrincipalGetAdapter::principal(), and provRecorder_.
Referenced by cacheIdentifier(), commit_aux(), eventSelectionIDs(), getByProductID_(), getProvenance(), makeProductID(), and processHistoryID().
EventSelectionIDVector const & Event::eventSelectionIDs | ( | ) | const |
Definition at line 70 of file Event.cc.
References eventPrincipal(), and edm::EventPrincipal::eventSelectionIDs().
void Event::fillView_ | ( | BasicHandle & | bh, |
Handle< View< ELEMENT > > & | result | ||
) | const |
Definition at line 554 of file Event.h.
References addToGotBranchIDs(), edm::WrapperBase::fillView(), gotViews_, h, edm::BasicHandle::id(), productGetter(), edm::BasicHandle::provenance(), mps_fire::result, and edm::BasicHandle::wrapper().
Referenced by get(), getByLabel(), and getByToken().
Definition at line 331 of file Event.h.
References addToGotBranchIDs(), edm::HandleBase::clear(), edm::convert_handle(), edm::HandleBase::failedToGet(), getByProductID_(), eostools::move(), and edm::BasicHandle::provenance().
Referenced by Options.Options::__getitem__(), betterConfigParser.BetterConfigParser::__updateDict(), rrapi.RRApi::columns(), rrapi.RRApi::count(), rrapi.RRApi::data(), edm::EdmEventItemGetter< RefType >::get(), betterConfigParser.BetterConfigParser::getCompares(), betterConfigParser.BetterConfigParser::getGeneral(), betterConfigParser.BetterConfigParser::getResultingSection(), edm::makeRefToBaseProdFrom(), RecoTauJetRegionProducer::produce(), RecoTauPiZeroProducer::produce(), RctRawToDigi::produce(), GctRawToDigi::produce(), PFRecoTauChargedHadronProducer::produce(), pat::PATTriggerEventProducer::produce(), rrapi.RRApi::report(), rrapi.RRApi::reports(), rrapi.RRApi::tables(), rrapi.RRApi::tags(), rrapi.RRApi::templates(), and rrapi.RRApi::workspaces().
bool Event::get | ( | ProductID const & | oid, |
Handle< View< ELEMENT > > & | result | ||
) | const |
Definition at line 344 of file Event.h.
References edm::BasicHandle::failedToGet(), fillView_(), getByProductID_(), edm::makeHandleExceptionFactory(), edm::errors::ProductNotFound, mps_fire::result, and groupFilesInBlocks::temp.
Referenced by Options.Options::__getitem__(), betterConfigParser.BetterConfigParser::__updateDict(), rrapi.RRApi::columns(), rrapi.RRApi::count(), rrapi.RRApi::data(), betterConfigParser.BetterConfigParser::getCompares(), betterConfigParser.BetterConfigParser::getGeneral(), betterConfigParser.BetterConfigParser::getResultingSection(), rrapi.RRApi::report(), rrapi.RRApi::reports(), rrapi.RRApi::tables(), rrapi.RRApi::tags(), rrapi.RRApi::templates(), and rrapi.RRApi::workspaces().
void Event::getAllProvenance | ( | std::vector< Provenance const * > & | provenances | ) | const |
Definition at line 90 of file Event.cc.
References edm::Principal::getAllProvenance(), edm::PrincipalGetAdapter::principal(), and provRecorder_.
Referenced by cms::ProducerAnalyzer::analyze(), cms::Analyzer_minbias::analyze(), GlobalDigisHistogrammer::analyze(), GlobalRecHitsHistogrammer::analyze(), MuonSimHitsValidAnalyzer::analyze(), GlobalHitsHistogrammer::analyze(), GlobalHitsAnalyzer::analyze(), GlobalDigisAnalyzer::analyze(), GlobalRecHitsAnalyzer::analyze(), edm::EventContentAnalyzer::analyze(), FWFFMetadataManager::hasModuleLabel(), EcalDeadCellTriggerPrimitiveFilter::loadEventInfoForFilter(), TrackerHitProducer::produce(), GlobalHitsProdHist::produce(), GlobalHitsProducer::produce(), GlobalDigisProducer::produce(), and GlobalRecHitsProducer::produce().
bool edm::Event::getByLabel | ( | std::string const & | label, |
std::string const & | productInstanceName, | ||
Handle< GenericObject > & | result | ||
) | const |
Specialize the getByLabel method to work with a Handle<GenericObject>
Definition at line 51 of file GenericHandle.cc.
References edm::convert_handle(), diffTwoXMLs::label, eostools::move(), edm::BasicHandle::provenance(), mps_fire::result, and AlCaHLTBitMon_QueryRunRegistry::string.
bool edm::Event::getByLabel | ( | edm::InputTag const & | tag, |
Handle< GenericObject > & | result | ||
) | const |
Definition at line 66 of file GenericHandle.cc.
References edm::convert_handle(), eostools::move(), edm::BasicHandle::provenance(), mps_fire::result, and GlobalPosition_Frontier_DevDB_cff::tag.
bool edm::Event::getByLabel | ( | std::string const & | label, |
std::string const & | productInstanceName, | ||
Handle< GenericObject > & | result | ||
) | const |
Specialize the Event's getByLabel method to work with a Handle<GenericObject>
bool edm::Event::getByLabel | ( | edm::InputTag const & | tag, |
Handle< GenericObject > & | result | ||
) | const |
bool Event::getByLabel | ( | InputTag const & | tag, |
Handle< PROD > & | result | ||
) | const |
Definition at line 418 of file Event.h.
References addToGotBranchIDs(), edm::HandleBase::clear(), edm::convert_handle(), edm::HandleBase::failedToGet(), edm::PrincipalGetAdapter::getByLabel_(), moduleCallingContext_, eostools::move(), PROD, edm::HandleBase::provenance(), and provRecorder_.
Referenced by CastorDigiProducer::accumulate(), HcalTBDigiProducer::accumulate(), HGCDigitizer::accumulate(), SiStripDigitizer::accumulate(), HcalDigitizer::accumulate(), cms::SiPixelDigitizer::accumulate(), EcalDigiProducer::accumulate(), edm::HiMixingWorker< T >::addSignals(), edm::MixingWorker< T >::addSignals(), edm::DataMixingSiStripMCDigiWorker::addSiStripSignals(), SiStripGainCosmicCalculator::algoAnalyze(), SiStripQualityHotStripIdentifier::algoAnalyze(), SiStripGainFromData::algoAnalyze(), PartonJetCorrectionExample::analyze(), FlavorJetCorrectionExample::analyze(), CSCTruthTest::analyze(), RHStopDump::analyze(), CSCAFEBAnalyzer::analyze(), ElectronIDAnalyzer::analyze(), EcalStatusAnalyzer::analyze(), SimpleJetDump::analyze(), CastorDigiAnalyzerImpl::analyze(), CastorHitAnalyzerImpl::analyze(), evf::EvFRecordInserter::analyze(), evf::EvFRecordUnpacker::analyze(), CaloTowersExample::analyze(), RawDataConverter::analyze(), EcalMatacqAnalyzer::analyze(), JetToDigiDump::analyze(), myFastSimVal::analyze(), CMSDAS11DijetAnalyzer::analyze(), CMSDAS11DijetTestAnalyzer::analyze(), JetCorExample< Jet >::analyze(), JetPlotsExample< Jet >::analyze(), JetValidation::analyze(), EcalPerEvtMatacqAnalyzer::analyze(), EcalTBTDCRawInfoDumper::analyze(), EcalTBHodoscopeRawInfoDumper::analyze(), JetAnaPythia< Jet >::analyze(), CastorHitAnalyzer::analyze(), PlaybackRawDataProvider::analyze(), CastorDigiAnalyzer::analyze(), HcalHitAnalyzerImpl::analyze(), EcalDCCHeaderDisplay::analyze(), EcalDigiDisplay::analyze(), myRawAna::analyze(), HcalHitAnalyzer::analyze(), EcalPnGraphs::analyze(), RivetHarvesting::analyze(), TauGenJetDumper::analyze(), HcalDigiAnalyzerImpl::analyze(), HcalDigiAnalyzer::analyze(), GenMuonRadCorrAnalyzer::analyze(), MCElectronAnalyzer::analyze(), MCPhotonAnalyzer::analyze(), MCPizeroAnalyzer::analyze(), PhotonsWithConversionsAnalyzer::analyze(), SimpleConvertedPhotonAnalyzer::analyze(), DijetMass< Jet >::analyze(), AlignmentStats::analyze(), GctDigiToPsbText::analyze(), RawToText::analyze(), TreeWriterForEcalCorrection::analyze(), HcalTB06Analysis::analyze(), L1CaloInputScaleTester::analyze(), CSCTFanalyzer::analyze(), AcceptanceHistoProducer::analyze(), PFCandidateChecker::analyze(), RecoTauPlotDiscriminator::analyze(), EmbeddingKineReweightNtupleProducer::analyze(), HLTInspect::analyze(), test::GlobalNumbersAnalysis::analyze(), ValidationMisalignedTracker::analyze(), RctDigiToRctText::analyze(), ElectronSeedAnalyzer::analyze(), EcalPedHists::analyze(), miscalibExample::analyze(), GctFibreAnalyzer::analyze(), EcalHexDisplay::analyze(), EcalTPInputAnalyzer::analyze(), HTMHTAnalyzer::analyze(), SiStripLAProfileBooker::analyze(), PatPhotonSimpleAnalyzer::analyze(), PhotonIDSimpleAnalyzer::analyze(), EcalPerEvtLaserAnalyzer::analyze(), EcalTPGAnalyzer::analyze(), EcalABAnalyzer::analyze(), SimplePhotonAnalyzer::analyze(), EcalTestPulseAnalyzer::analyze(), EcalTrigPrimAnalyzer::analyze(), CSCViewDigi::analyze(), AnaL1CaloCleaner::analyze(), GctTimingAnalyzer::analyze(), GsfElectronMCFakeAnalyzer::analyze(), L1GctValidation::analyze(), GsfElectronDataAnalyzer::analyze(), GsfElectronFakeAnalyzer::analyze(), Mixing2DB::analyze(), LaserAlignmentT0ProducerDQM::analyze(), DQMAnalyzer::analyze(), GsfElectronMCAnalyzer::analyze(), EcalSimpleTBAnalyzer::analyze(), RctDigiToSourceCardText::analyze(), EcalSimple2007H4TBAnalyzer::analyze(), L1RCTRelValAnalyzer::analyze(), SimplePi0DiscAnalyzer::analyze(), SiStripElectronAnalyzer::analyze(), DTTrigTest::analyze(), ElectronCalibration::analyze(), EcalLaserAnalyzer2::analyze(), myJetAna::analyze(), EcalPulseShapeGrapher::analyze(), SiPixelDQMRocLevelAnalyzer::analyze(), EcalLaserAnalyzer::analyze(), TestPythiaDecays::analyze(), __class__< T >::analyze(), TestHits::analyze(), HitEff::analyze(), TestSmoothHits::analyze(), EGEnergyAnalyzer::analyze(), EcalBxOrbitNumberGrapher::analyze(), AnaMuonCaloCleaner::analyze(), L1ExtraTestAnalyzer::analyze(), TestMuonCaloCleaner::analyze(), calcTopMass::analyze(), L1RCTTestAnalyzer::analyze(), ElectronCalibrationUniv::analyze(), TestTrackHits::analyze(), EcalURecHitHists::analyze(), TestOutliers::analyze(), EcalLaserAnalyzerYousi::analyze(), TreeProducerCalibSimul::analyze(), LhcTrackAnalyzer::analyze(), CastorDumpConditions::analyze(), DummyEvelyser::analyze(), EcalMipGraphs::analyze(), PhotonValidator::analyze(), EcalDisplaysByEvent::analyze(), CollectionDumper< T >::analyze(), EopTreeWriter::analyze(), AlignmentMonitorAsAnalyzer::analyze(), EcalCosmicsHists::analyze(), CastorPedestalsAnalysis::analyze(), PrimaryVertexValidation::analyze(), SiStripBaselineAnalyzer::analyze(), GctErrorAnalyzer::analyze(), DiagMaker::analyze(), L1MuonRecoTreeProducer::analyze(), DijetRatio< Jet >::analyze(), EcnaAnalyzer::analyze(), MCEmbeddingValidationAnalyzer::analyze(), edm::EventContentAnalyzer::analyze(), L1GtPackUnpackAnalyzer::analyzeGMT(), L1GtPackUnpackAnalyzer::analyzeGT(), GlobalTrackerMuonAlignment::analyzeTrackTrack(), GlobalTrackerMuonAlignment::analyzeTrackTrajectory(), SegmentToTrackAssociator::associate(), PFRecoTauDiscriminationByFlight::beginEvent(), RecoTauDiscriminationByGenMatch::beginEvent(), tautools::RecoTauDistanceFromTruthPlugin::beginEvent(), reco::tau::RecoTauDiscriminantFromDiscriminator::beginEvent(), reco::tau::RecoTauDiscriminationBinnedIsolation::beginEvent(), tautools::RecoTauDecayModeTruthMatchPlugin::beginEvent(), RecoTauMVATransform::beginEvent(), CaloRecoTauAlgorithm::buildCaloTau(), edm::MixingWorker< T >::checkSignal(), SiStripZeroSuppression::CollectionMergedZeroSuppression(), L1GtDataEmulAnalyzer::compareDaqRecord(), ShallowTree::TypedBranchConnector< T >::connect(), L1FastjetCorrector::correction(), L1OffsetCorrector::correction(), L6SLBCorrector::correction(), SelectReplacementCandidates::determineMuonsToUse(), SelectReplacementCandidates::determineMuonsToUse_old(), EcalCosmicsHists::determineTriggers(), DumpGctDigis::doEM(), DumpGctDigis::doEnergySums(), DumpGctDigis::doFibres(), DumpGctDigis::doInternEM(), DumpGctDigis::doJets(), edm::MixingModule::doPileUp(), DumpGctDigis::doRctEM(), DumpGctDigis::doRegions(), InvRingCalib::duringLoop(), EcalEleCalibLooper::duringLoop(), ZeeCalibration::duringLoop(), AlignmentProducer::duringLoop(), AlignmentMonitorTracksFromTrajectories::event(), AlignmentMonitorSegmentDifferences::event(), AlignmentMonitorMuonSystemMap1D::event(), AlignmentMonitorMuonVsCurvature::event(), L1GtPatternGenerator::extractGlobalTriggerData(), L1TMuon::CSCCollector::extractPrimitives(), L1TMuon::RPCCollector::extractPrimitives(), extractRecordData(), PFElectronTranslator::fetchCandidateCollection(), PFPhotonTranslator::fetchCandidateCollection(), PFElectronTranslator::fetchGsfCollection(), StringBasedNTupler::fill(), AdHocNTupler::fill(), HTrackAssociator::fillCaloTowers(), LaserAlignment::fillDataProfiles(), HTrackAssociator::fillEcal(), MuonCaloCleanerAllCrossed::fillEnergyDepositMap(), HTrackAssociator::fillHcal(), HTrackAssociator::fillHcalTowers(), MCEmbeddingValidationAnalyzer::plotEntryTypeEvtWeight::fillHistograms(), MCEmbeddingValidationAnalyzer::leptonDistributionT< T >::fillHistograms(), MCEmbeddingValidationAnalyzer::electronDistributionExtra::fillHistograms(), MCEmbeddingValidationAnalyzer::tauDistributionExtra::fillHistograms(), MCEmbeddingValidationAnalyzer::leptonEfficiencyT< T >::fillHistograms(), MCEmbeddingValidationAnalyzer::leptonL1TriggerEfficiencyT1T2< T1, T2 >::fillHistograms(), MCEmbeddingValidationAnalyzer::l1ExtraObjectDistributionT< T >::fillHistograms(), MCEmbeddingValidationAnalyzer::metDistributionType::fillHistograms(), MCEmbeddingValidationAnalyzer::metL1TriggerEfficiencyType::fillHistograms(), PhotonMVAEstimatorRun2Phys14NonTrig::fillMVAVariables(), PhotonMVAEstimatorRun2Spring15NonTrig::fillMVAVariables(), ElectronMVAEstimatorRun2Spring15Trig::fillMVAVariables(), ElectronMVAEstimatorRun2Spring15NonTrig::fillMVAVariables(), BTagSkimMC::filter(), RecoTauDifferenceAnalyzer::filter(), ptHatFilter::filter(), myFilter::filter(), PFMETFilter::filter(), PFFilter::filter(), cms::MTCCHLTrigger::filter(), cms::CosmicTIFTrigFilter::filter(), STFilter::filter(), CosmicGenFilterLowE::filter(), ComphepSingletopFilter::filter(), ComphepSingletopFilterPy8::filter(), cms::TrackMTCCFilter::filter(), GaussianZBeamSpotFilter::filter(), BTagSkimLeptonJet::filter(), cms::BHFilter::filter(), cms::ClusterMTCCFilter::filter(), cms::TECClusterFilter::filter(), HeavyQuarkFromMPIFilterAlgo::filter(), CandViewRefRandomSelector::filter(), EcalTangentFilter::filter(), L1Filter::filter(), doubleEMEnrichingFilterAlgo::filter(), BxNumberFilter::filter(), RecoDiMuon::filter(), HighETPhotonsFilterAlgo::filter(), L1DEFilter::filter(), TotalKinematicsFilter::filter(), LHEDYdecayFilter::filter(), XtoFFbarFilter::filter(), GenMuonRadiationFilter::filter(), MuonRadiationFilter::filter(), PFTauViewRefSelector::filter(), UniqueObjectSelector< T >::filter(), GenLeadTrackFilter::filter(), TauHadronDecayFilter::filter(), MuonAlignmentPreFilter::filter(), BeamSplash::filter(), ECALActivity::filter(), JGJFilter::filter(), SelectHFMinBias::filter(), IsTBH4Type::filter(), RecHitEnergyFilter::filter(), EcalExclusiveTrigFilter::filter(), MCMultiParticleFilter::filter(), PythiaFilterHT::filter(), TwoVBGenFilter::filter(), LQGenFilter::filter(), Zto2lFilter::filter(), __class__< T >::filter(), MCLongLivedParticles::filter(), SecondaryVertexFilter::filter(), HcalHPDFilter::filter(), TagProbeMassEDMFilter::filter(), SelectZmumuevents::filter(), DYGenFilter::filter(), CSCOverlapsBeamSplashCut::filter(), PythiaMomDauFilter::filter(), L1GtBeamModeFilter::filter(), PhotonEnrichmentFilter::filter(), EcalSkim::filter(), FilterScrapingPixelProbability::filter(), EmptyEventsFilter::filter(), ProtonTaggerFilter::filter(), EcalRecHitsFilter::filter(), UEDMultiLeptonFilter::filter(), RecoTauDiscriminatorRefSelectorImpl< T >::filter(), HCALHighEnergyFilter::filter(), SimpleJetFilter::filter(), NJetsMC::filter(), reco::tau::AssociationMatchRefSelector< InputType, MatchedType, OutputType, ClonePolicy >::filter(), WZInterestingEventSelector::filter(), RPCRecHitFilter::filter(), ShallowDigisProducer::findInput(), findMuons(), RunManager::generateEvent(), gen::PyquenHadronizer::generatePartonsAndHadronize(), gen::HydjetHadronizer::generatePartonsAndHadronize(), gen::Hydjet2Hadronizer::generatePartonsAndHadronize(), getByLabel(), L1MuGMTPSB::getCalo(), PFClusterShapeProducer::getClusterCollection(), RawDataConverter::GetDigis(), EcalClusterPUCleaningTools::getEBRecHits(), EcalClusterPUCleaningTools::getEERecHits(), HoECalculator::getHoE(), CaloRecoTauTagInfoAlgorithm::getNeutralEcalBasicClusters(), PFClusterShapeProducer::getRecHitCollection(), getSelMuons(), RawDataConverter::GetValidLabels(), LeptonRecoSkim::handleObjects(), EcalFEDErrorFilter::hltFilter(), TrackerMuonHitExtractor::init(), DTHitAssociator::initEvent(), RPCHitAssociator::initEvent(), GEMHitAssociator::initEvent(), HcalTBDigiProducer::initializeEvent(), CalibrationTrackSelector::isIsolated(), OMTFReconstruction::loadAndFilterDigis(), SiStripAPVRestorer::LoadMeanCMMap(), CosmicParametersDefinerForTP::momentum(), ParametersDefinerForTP::momentum(), tfwliteselectortest::ThingsWorker::process(), tfwliteselectortest::ThingsTSelector::process(), __class__Worker::process(), PixelVertexProducerMedian::produce(), VZeroProducer::produce(), HepMCCopy::produce(), ElectronSqPtTkIsolationProducer::produce(), MuonWithPFIsoProducerCopy::produce(), EcalTBH2TDCRecInfoProducer::produce(), EcalTBTDCRecInfoProducer::produce(), EcalTBHodoscopeRecInfoProducer::produce(), ShallowSimhitClustersProducer::produce(), PFConcretePFCandidateProducer::produce(), PFMuonCaloCleaner::produce(), CastorFastTowerProducer::produce(), HectorProducer::produce(), EgammaElectronTkIsolationProducer::produce(), EgammaPhotonTkIsolationProducer::produce(), EgammaPhotonTkNumIsolationProducer::produce(), CastorFastClusterProducer::produce(), EcalTBWeightUncalibRecHitProducer::produce(), HLTHFRecoEcalCandidateProducer::produce(), PFElectronTranslator::produce(), EgammaElectronTkNumIsolationProducer::produce(), CandViewRefTriggerBiasRemover::produce(), PFTauViewRefMerger::produce(), MixedGenMEtProducer::produce(), AlignmentPrescaler::produce(), FastTSGFromL2Muon::produce(), StripCompactDigiSimLinksProducer::produce(), RecoTauPiZeroFlattener::produce(), LHECOMWeightProducer::produce(), RawDataSelector::produce(), SiPixelFedFillerWordEventNumber::produce(), EcalDCCTBUnpackingModule::produce(), TkAlCaOverlapTagger::produce(), BaseEvtVtxGenerator::produce(), reco::tautools::CopyProducer< Collection >::produce(), L1ExtraMEtMixerPlugin::produce(), EcalDCCTB07UnpackingModule::produce(), L1GctInternJetProducer::produce(), ImpactParameter::produce(), MuonDetRecHitMixer< T1, T2 >::produce(), cms::ReconstructerFP420::produce(), CaloRecoTauProducer::produce(), DigiSimLinkProducer::produce(), SimpleTrackListMerger::produce(), reco::tautools::CastedRefProducer< DerivedCollection, BaseType >::produce(), SubsystemNeutronWriter::produce(), TrackListMerger::produce(), L1ExtraMixerPluginT< T >::produce(), EgammaTowerIsolationProducer::produce(), PFTauMVAInputDiscriminantTranslator::produce(), EgammaEcalRecHitIsolationProducer::produce(), MuonPFCandidateCleaner::produce(), GenParticlesFromZsSelectorForMCEmbedding::produce(), MatchedProbeMaker< T >::produce(), CaloRecoTauTagInfoProducer::produce(), MCParticleReplacer::produce(), edm::CFWriter::produce(), EmbeddingKineReweightProducer::produce(), LaserAlignmentT0Producer::produce(), TagProbeMassProducer::produce(), cms::TrackerizerFP420::produce(), L1RCTTPGProvider::produce(), MuonCaloCleanerByDistance::produce(), EcalRecHitRecalib::produce(), L1ExtraParticleMapProd::produce(), L1GctEmulator::produce(), pat::__class__Producer::produce(), L1EmulBias::produce(), cms::ClusterizerFP420::produce(), NeutronHitsCollector::produce(), L1ExtraParticlesProd::produce(), LTCRawToDigi::produce(), GSFElectronsMixer::produce(), MaskedRctInputDigiProducer::produce(), cms::DigitizerFP420::produce(), BSCTrigger::produce(), RctRawToDigi::produce(), EcalFEDWithCRCErrorProducer::produce(), GsfTrackMixer::produce(), RochesterCorrMuonProducerT< T >::produce(), CaloRecHitMixer< T >::produce(), ElectronSeedTrackRefUpdater::produce(), L1RCTProducer::produce(), RPCTrigger::produce(), ElectronSeedTrackRefUpdaterAndMerger::produce(), TruthTauDecayModeProducer::produce(), GctRawToDigi::produce(), MuonErrorMatrixAdjuster::produce(), ConvBremSeedProducer::produce(), L1GlobalTriggerEvmRawToDigi::produce(), LHE2HepMCConverter::produce(), PFCandidateMixer::produce(), SiStripMeanCMExtractor::produce(), AlignmentMuonHIPTrajectorySelector::produce(), pat::PATTriggerEventProducer::produce(), L1GlobalTrigger::produce(), L1GlobalTriggerRawToDigi::produce(), PFPhotonTranslator::produce(), JetIdSelector< T >::produce(), pat::PATTriggerProducer::produce(), TrackerToMuonPropagator::produce(), CSCOverlapsTrackPreparation::produce(), JetCrystalsAssociator::produce(), MuonMCClassifier::produce(), RPCTechnicalTrigger::produce(), L1TCaloLayer1RawToDigi::produce(), HepMCSplitter::produce(), NuclearTrackCorrector::produce(), PFTau3ProngReco::produce(), GlobalMuonTrackMixer::produceTrackExtras(), GlobalMuonTrackCleaner::produceTrackExtras(), TeVMuonTrackCleaner::produceTrackExtras(), TeVMuonTrackMixer::produceTrackExtras(), TrackMixerBase::produceTracks(), MuonTrackCleanerBase::produceTracks(), readEventData(), L1MuGMTPSB::receiveData(), L1GlobalTriggerPSB::receiveGctObjectData(), L1GlobalTriggerGTL::receiveGmtObjectData(), L1GlobalTriggerPSB::receiveTechnicalTriggers(), RunManager::resetGenParticleId(), KFBasedPixelFitter::run(), SingleEleCalibSelector::select(), L1Analysis::L1AnalysisSimulation::Set(), L1Analysis::L1AnalysisEvent::Set(), StringBranchHelper< Object, Collection >::StringBranchHelper(), StringLeaveHelper< Object >::StringLeaveHelper(), LaserDQM::trackerStatistics(), GsfElectronDataAnalyzer::trigger(), DQMAnalyzer::trigger(), DTTrig::triggerReco(), triggerResultsByName(), MuonIdTruthInfo::truthMatchMuon(), CosmicParametersDefinerForTP::vertex(), and ParametersDefinerForTP::vertex().
bool Event::getByLabel | ( | std::string const & | label, |
Handle< PROD > & | result | ||
) | const |
Definition at line 446 of file Event.h.
References emptyString_, and getByLabel().
bool Event::getByLabel | ( | std::string const & | label, |
std::string const & | productInstanceName, | ||
Handle< PROD > & | result | ||
) | const |
Definition at line 431 of file Event.h.
References addToGotBranchIDs(), edm::HandleBase::clear(), edm::convert_handle(), emptyString_, edm::HandleBase::failedToGet(), edm::PrincipalGetAdapter::getByLabel_(), moduleCallingContext_, eostools::move(), PROD, edm::HandleBase::provenance(), and provRecorder_.
bool Event::getByLabel | ( | std::string const & | label, |
Handle< View< ELEMENT > > & | result | ||
) | const |
Definition at line 519 of file Event.h.
References emptyString_, getByLabel(), and mps_fire::result.
bool Event::getByLabel | ( | std::string const & | label, |
std::string const & | productInstanceName, | ||
Handle< View< ELEMENT > > & | result | ||
) | const |
Definition at line 503 of file Event.h.
References emptyString_, edm::BasicHandle::failedToGet(), fillView_(), edm::PrincipalGetAdapter::getMatchingSequenceByLabel_(), h, moduleCallingContext_, eostools::move(), provRecorder_, mps_fire::result, edm::HandleBase::swap(), and edm::BasicHandle::whyFailedFactory().
bool Event::getByLabel | ( | InputTag const & | tag, |
Handle< View< ELEMENT > > & | result | ||
) | const |
Definition at line 489 of file Event.h.
References edm::BasicHandle::failedToGet(), fillView_(), edm::PrincipalGetAdapter::getMatchingSequenceByLabel_(), h, moduleCallingContext_, eostools::move(), provRecorder_, mps_fire::result, edm::HandleBase::swap(), and edm::BasicHandle::whyFailedFactory().
|
privatevirtual |
Implements edm::EventBase.
Definition at line 197 of file Event.cc.
References addToGotBranchIDs(), edm::PrincipalGetAdapter::getByLabel_(), h, edm::BasicHandle::isValid(), moduleCallingContext_, edm::BasicHandle::provenance(), and provRecorder_.
|
private |
Definition at line 107 of file Event.cc.
References eventPrincipal(), and edm::EventPrincipal::getByProductID().
Referenced by get(), and getImpl().
bool Event::getByToken | ( | EDGetToken | token, |
Handle< PROD > & | result | ||
) | const |
Definition at line 462 of file Event.h.
References addToGotBranchIDs(), edm::HandleBase::clear(), edm::convert_handle(), edm::HandleBase::failedToGet(), edm::PrincipalGetAdapter::getByToken_(), moduleCallingContext_, eostools::move(), PROD, edm::PRODUCT_TYPE, edm::HandleBase::provenance(), and provRecorder_.
Referenced by hcaldqm::DQTask::_getCalibType(), PedestalTask::_isApplicable(), LEDTask::_isApplicable(), LaserTask::_isApplicable(), RadDamTask::_process(), DigiComparisonTask::_process(), TPComparisonTask::_process(), TPTask::_process(), PedestalTask::_process(), RawTask::_process(), LEDTask::_process(), RecHitTask::_process(), LaserTask::_process(), DigiTask::_process(), pat::PATUserDataMerger< ObjectType, Operation >::add(), edm::DataMixingEMWorker::addEMSignals(), edm::DataMixingEMDigiWorker::addEMSignals(), edm::DataMixingGeneralTrackWorker::addGeneralTrackSignals(), edm::DataMixingHcalWorker::addHcalSignals(), BetaCalculatorRPC::addInfoToCandidate(), BetaCalculatorECAL::addInfoToCandidate(), edm::DataMixingMuonWorker::addMuonSignals(), edm::DataMixingSiPixelWorker::addSiPixelSignals(), edm::DataMixingSiPixelMCDigiWorker::addSiPixelSignals(), edm::DataMixingSiStripWorker::addSiStripSignals(), edm::DataMixingSiStripRawWorker::addSiStripSignals(), edm::DataMixingTrackingParticleWorker::addTrackingParticleSignals(), DeDxDiscriminatorLearner::algoAnalyze(), SiStripMonitorTrack::AllClusters(), BjetAnalysis::analyze(), DimuonStatistics::analyze(), GlbMuQualityCutsAnalysis::analyze(), AlphaTVarAnalyzer::analyze(), HLTTauRelvalQTester::analyze(), ScoutingTestAnalyzer::analyze(), GEMSimTrackMatch::analyze(), CSCDigiDump::analyze(), RazorVarAnalyzer::analyze(), GEMHitsValidation::analyze(), GEMRecHitsValidation::analyze(), MatchMETBenchmarkAnalyzer::analyze(), METBenchmarkAnalyzer::analyze(), PFCandidateBenchmarkAnalyzer::analyze(), PFCandidateManagerAnalyzer::analyze(), HcalCableMapper::analyze(), DQMHOAlCaRecoStream::analyze(), CandidateBenchmarkAnalyzer::analyze(), HcalTrigPrimMonitor::analyze(), CSCDigiToPattern::analyze(), DiJetVarAnalyzer::analyze(), CSCRecHit2DValidation::analyze(), CSCSegmentValidation::analyze(), CSCALCTDigiValidation::analyze(), CSCCLCTDigiValidation::analyze(), CSCStripDigiValidation::analyze(), PerformanceAnalyzer::analyze(), HcalNZSMonitor::analyze(), CSCWireDigiValidation::analyze(), PFCandidateDQMAnalyzer::analyze(), PFJetDQMAnalyzer::analyze(), PFMETDQMAnalyzer::analyze(), PFMuonDQMAnalyzer::analyze(), CSCComparatorDigiValidation::analyze(), GEMDigiTrackMatch::analyze(), ESRecoSummary::analyze(), HLTTauDQML1Plotter::analyze(), GEMRecHitTrackMatch::analyze(), L1Scalers::analyze(), GenericBenchmarkAnalyzer::analyze(), MultiTrackValidatorGenPs::analyze(), PatTauAnalyzer::analyze(), PatZjetsElectronAnalyzer::analyze(), PatZjetsJetAnalyzer::analyze(), L1TScalersSCAL::analyze(), ESOccupancyTask::analyze(), ESPedestalTask::analyze(), PatElectronAnalyzer::analyze(), KVFTrackUpdate::analyze(), TopElecAnalyzer::analyze(), TopJetAnalyzer::analyze(), TopMuonAnalyzer::analyze(), TopTauAnalyzer::analyze(), ESIntegrityTask::analyze(), ESRawDataTask::analyze(), PFTester::analyze(), MultiTrackValidator::analyze(), RPCPointVsRecHit::analyze(), SiPixelDigiValid::analyze(), SiStripDigiValid::analyze(), HcalCoarsePedestalMonitor::analyze(), HcalNoiseMonitor::analyze(), L1TdeStage2EMTF::analyze(), TopGenEventAnalyzer::analyze(), BTagPerformanceAnalyzerOnData::analyze(), ESDcsInfoTask::analyze(), HiBasicGenTest::analyze(), L1TStage2MuonComp::analyze(), ESFEDIntegrityTask::analyze(), PatMCMatchingExtended::analyze(), PatMCMatching::analyze(), PatTriggerAnalyzer::analyze(), PatTriggerTagAndProbe::analyze(), RPCMonitorRaw::analyze(), ZdcTBAnalyzer::analyze(), HcalTBWriter::analyze(), L1TStage2EMTF::analyze(), L1TStage2uGMT::analyze(), CentralityDQM::analyze(), QcdHighPtDQM::analyze(), SiStripFEDDumpPlugin::analyze(), CaloTowerAnalyzer::analyze(), PatTopSelectionAnalyzer::analyze(), DigiAnalyzer::analyze(), L1TStage2CaloLayer2::analyze(), SiStripMonitorFilter::analyze(), SiStripMonitorHLT::analyze(), FTSLuminosityFromPileupSummaryInfo::analyze(), FTSLuminosityFromPixelClusters::analyze(), EgammaBasicClusters::analyze(), EventShapeDQM::analyze(), ElectronMcSignalValidator::analyze(), HcalBeamMonitor::analyze(), RPCRecHitValid::analyze(), HistoAnalyzer< C >::analyze(), L1THIonImp::analyze(), RPCMonitorLinkSynchro::analyze(), TriggerSummaryAnalyzerAOD::analyze(), TriggerSummaryAnalyzerRAW::analyze(), ElectronGeneralAnalyzer::analyze(), HCALRecHitAnalyzer::analyze(), FTSLuminosityFromVertices::analyze(), SUSYDQMAnalyzer::analyze(), JetResolutionDemo::analyze(), PatBasicAnalyzer::analyze(), PatBTagAnalyzer::analyze(), RivetAnalyzer::analyze(), TrackTypeMonitor::analyze(), ElectronTagProbeAnalyzer::analyze(), EgammaSuperClusters::analyze(), PrimaryVertexMonitor::analyze(), L1TSummary::analyze(), L1TBasicDemo::analyze(), ESTimingTask::analyze(), ESTrendTask::analyze(), DQMMessageLogger::analyze(), HcalRecHitMonitor::analyze(), EwkMuDQM::analyze(), MonitorLTC::analyze(), StandaloneTrackMonitor::analyze(), EcalDQMonitorTask::analyze(), HeavyIonUCCDQM::analyze(), BTagPerformanceAnalyzerMC::analyze(), TtFullHadSignalSelMVATrainer::analyze(), EcalFEDMonitorTemp< SUBDET >::analyze(), HLTTauDQMOfflineSource::analyze(), PFTauElecRejectionBenchmarkAnalyzer::analyze(), CSCTFAnalyzer::analyze(), ObjectCounter< C >::analyze(), DQMHcalPhiSymAlCaReco::analyze(), PUDumper::analyze(), TtSemiLepJetCombMVATrainer::analyze(), EwkElecDQM::analyze(), HLTEventAnalyzerAOD::analyze(), HLTEventAnalyzerRAW::analyze(), DQMHcalIsolatedBunchAlCaReco::analyze(), JetCorrectorDemo::analyze(), L1TGlobalSummary::analyze(), RPCFEDIntegrity::analyze(), AlCaElectronsTest::analyze(), AlcaBeamMonitor::analyze(), SUSY_HLT_InclusiveHT::analyze(), TtSemiLepSignalSelMVATrainer::analyze(), JetCorrectorOnTheFly< Jet >::analyze(), BPhysicsOniaDQM::analyze(), SiStripMonitorDigi::analyze(), SiStripBaselineValidator::analyze(), TkAlCaRecoMonitor::analyze(), DQMHcalDiJetsAlCaReco::analyze(), TKStatus::analyze(), SimHitsValidationHcal::analyze(), AnalysisRootpleProducerOnlyMC::analyze(), EcalPileUpDepMonitor::analyze(), SUSY_HLT_PhotonHT::analyze(), SUSY_HLT_PhotonMET::analyze(), MuonRecoAnalyzer::analyze(), WValidation::analyze(), HcalSimHitStudy::analyze(), MixCollectionValidation::analyze(), TrackerHitAnalyzer::analyze(), SiPixelRecHitsValid::analyze(), HcalDeadCellMonitor::analyze(), HcalRawDataMonitor::analyze(), EwkMuLumiMonitorDQM::analyze(), PixelVTXMonitor::analyze(), HLTVertexPerformanceAnalyzer::analyze(), BasicHepMCHeavyIonValidation::analyze(), ElectronStudy::analyze(), DQMLumiMonitor::analyze(), L1TdeGCT::analyze(), QcdPhotonsDQM::analyze(), DQMSourceEleCalib::analyze(), SUSY_HLT_DoubleMuon_Hadronic::analyze(), SUSY_HLT_Muon_BJet::analyze(), MuonSeedsAnalyzer::analyze(), DrellYanValidation::analyze(), ElectronMcFakeValidator::analyze(), dEdxHitAnalyzer::analyze(), VertexMonitor::analyze(), KVFTest::analyze(), DiMuonHistograms::analyze(), MuonEnergyDepositAnalyzer::analyze(), EcalPreshowerNoiseDistrib::analyze(), BasicGenParticleValidation::analyze(), BasicHepMCValidation::analyze(), ElectronMcSignalValidatorMiniAOD::analyze(), HcalDataIntegrityTask::analyze(), HcalDetDiagNoiseMonitor::analyze(), IsolatedParticlesGeneratedJets::analyze(), L1TDEMON::analyze(), SiStripMonitorCluster::analyze(), MonitorTrackResidualsBase< pixel_or_strip >::analyze(), dEdxAnalyzer::analyze(), TrackAnalyzer::analyze(), SimAnalyzerMinbias::analyze(), edm::InputAnalyzer::analyze(), MuonKinVsEtaAnalyzer::analyze(), MBUEandQCDValidation::analyze(), BxTiming::analyze(), CSCViewDigi::analyze(), KineExample::analyze(), SUSY_HLT_DoubleEle_Hadronic::analyze(), SUSY_HLT_Electron_BJet::analyze(), SegmentTrackAnalyzer::analyze(), BPhysicsSpectrum::analyze(), HiggsValidation::analyze(), BPhysicsValidation::analyze(), HcalBaseDQMonitor::analyze(), EwkDQM::analyze(), sistrip::SpyExtractRunModule::analyze(), ElectronAnalyzer::analyze(), ResolutionCreator::analyze(), ZeePlots::analyze(), HcalMonitorModule::analyze(), HcalHotCellMonitor::analyze(), WenuPlots::analyze(), StudyHLT::analyze(), L1TStage2OMTF::analyze(), HcalCorrPFCalculation::analyze(), RecAnalyzerMinbias::analyze(), FTSLuminosityFromScalers::analyze(), EfficiencyAnalyzer::analyze(), ParticleListDrawer::analyze(), BeamMonitor::analyze(), SUSY_HLT_alphaT::analyze(), cms::MinBias::analyze(), cms::ProducerAnalyzer::analyze(), TopDiLeptonDQM::analyze(), sistrip::SpyIdentifyRunsModule::analyze(), BeamSpotProblemMonitor::analyze(), HcalQLPlotAnal::analyze(), SUSY_HLT_DiJet_MET::analyze(), SUSY_HLT_ElecFakes::analyze(), SUSY_HLT_MuEle_Hadronic::analyze(), SUSY_HLT_Muon_Hadronic::analyze(), SUSY_HLT_MuonFakes::analyze(), SUSY_HLT_VBF_Mu::analyze(), RPCPhiEff::analyze(), OMTFPatternMaker::analyze(), HotlineDQM::analyze(), HLTBTagPerformanceAnalyzer::analyze(), SUSY_HLT_Razor::analyze(), EcalPreshowerDigisValidation::analyze(), EcalPreshowerRecHitsValidation::analyze(), DuplicationChecker::analyze(), JetTester::analyze(), AnalysisRootpleProducer::analyze(), HLTAnalyzer::analyze(), TrackSplittingMonitor::analyze(), HcalSimHitsValidation::analyze(), L1TDTTPG::analyze(), SiPixelHitEfficiencySource::analyze(), TrackEfficiencyMonitor::analyze(), V0Monitor::analyze(), edm::TestMix::analyze(), EcalBarrelSimHitsValidation::analyze(), NoiseRates::analyze(), L1RecoTreeProducer::analyze(), LumiMonitor::analyze(), L1TRCT::analyze(), ElectronConversionRejectionValidator::analyze(), EcalPreshowerSimHitsValidation::analyze(), EcalBarrelRecHitsValidation::analyze(), EcalEndcapSimHitsValidation::analyze(), TestSuite::analyze(), ZDCMonitorModule::analyze(), TrackParameterAnalyzer::analyze(), L1UpgradeTfMuonTreeProducer::analyze(), L1TFED::analyze(), MultiplicityCorrelator::analyze(), EcalEndcapRecHitsValidation::analyze(), SiStripMonitorRawData::analyze(), DQMHcalIsoTrackAlCaReco::analyze(), EcalZmassTask::analyze(), edm::TestMixedSource::analyze(), HcalNoiseRates::analyze(), ContainmentCorrectionAnalyzer::analyze(), EcalBarrelDigisValidation::analyze(), EcalEndcapDigisValidation::analyze(), TPGCheck::analyze(), BTVHLTOfflineSource::analyze(), GlobalTest::analyze(), L1ElectronRecoTreeProducer::analyze(), MuTriggerAnalyzer::analyze(), L1TCSCTPG::analyze(), HiggsDQM::analyze(), SiPixelHLTSource::analyze(), EnergyScaleAnalyzer::analyze(), HLTInclusiveVBFSource::analyze(), TagProbeFitTreeProducer::analyze(), L1TGMT::analyze(), L1TRPCTF::analyze(), SiPixelDigiSource::analyze(), ClusterCount::analyze(), GlobalMuonMatchAnalyzer::analyze(), PSMonitor::analyze(), L1TStage2uGT::analyze(), L1ABCDebugger::analyze(), SiPixelTrackResidualSource::analyze(), AnotherBeamSpotAnalyzer::analyze(), MuonIdDQM::analyze(), MuonRecoOneHLT::analyze(), GeneralHLTOffline::analyze(), FourVectorHLT::analyze(), HLTrigReport::analyze(), HitEff::analyze(), DQMSourcePi0::analyze(), B2GDoubleLeptonHLTValidation::analyze(), B2GHadronicHLTValidation::analyze(), B2GSingleLeptonHLTValidation::analyze(), EcalSimHitsValidation::analyze(), TopSingleLeptonHLTValidation::analyze(), L1TCaloLayer1Validator::analyze(), MCAcceptanceAnalyzer::analyze(), L1TRate::analyze(), PixelLumiDQM::analyze(), METTester::analyze(), BSvsPVAnalyzer::analyze(), L1MetFilterRecoTreeProducer::analyze(), L1UpgradeTreeProducer::analyze(), FFTJetImageRecorder::analyze(), RPCTTUMonitor::analyze(), DTScalerInfoTask::analyze(), TTbar_GenLepAnalyzer::analyze(), PhotonValidatorMiniAOD::analyze(), TestResolution::analyze(), DQMExample_Step1::analyze(), MultiplicityInvestigator::analyze(), SiPixelRawDataErrorSource::analyze(), cms::Analyzer_minbias::analyze(), TrackingMonitor::analyze(), HcalRecHitsAnalyzer::analyze(), HeavyFlavorValidation::analyze(), SUSY_HLT_SingleLepton::analyze(), TopDiLeptonHLTValidation::analyze(), EcalRecHitsValidation::analyze(), TauValidation::analyze(), HcalRecHitsValidation::analyze(), L1TStage2InputPatternWriter::analyze(), l1t::GtInputDump::analyze(), PFJetBenchmarkAnalyzer::analyze(), AnotherPrimaryVertexAnalyzer::analyze(), APVCyclePhaseMonitor::analyze(), QcdUeDQM::analyze(), SiPixelRecHitSource::analyze(), SiStripSpyMonitorModule::analyze(), TTbar_GenJetAnalyzer::analyze(), TTbarSpinCorrHepMCAnalyzer::analyze(), L1GtTrigReport::analyze(), ZDCDigiStudy::analyze(), HGCalDigiValidation::analyze(), HigPhotonJetHLTOfflineSource::analyze(), HLTMuonMatchAndPlotContainer::analyze(), TkConvValidator::analyze(), L1TdeRCT::analyze(), SusyDQM< Mu, Ele, Jet, Met >::analyze(), SiStripFEDCheckPlugin::analyze(), SiStripMonitorPedestals::analyze(), DTNoiseTask::analyze(), L1TRate_Offline::analyze(), l1t::L1TStage2CaloAnalyzer::analyze(), PFMETBenchmarkAnalyzer::analyze(), LogMessageMonitor::analyze(), TestOutliers::analyze(), DTLocalTriggerBaseTask::analyze(), TTbar_Kinematics::analyze(), GlobalDigisHistogrammer::analyze(), ZdcSimHitStudy::analyze(), MCVerticesAnalyzer::analyze(), L1GenTreeProducer::analyze(), PDFWeightsTest::analyze(), EventTimeDistribution::analyze(), ECALMultifitAnalyzer_HI::analyze(), L1ExtraTreeProducer::analyze(), HLTJetMETValidation::analyze(), l1t::L1TGlobalAnalyzer::analyze(), HcalRaddamMuon::analyze(), L1TStage2BMTF::analyze(), EcalDigisValidation::analyze(), BigEventsDebugger< T >::analyze(), Vx3DHLTAnalyzer::analyze(), DTLocalTriggerLutTask::analyze(), GlobalRecHitsHistogrammer::analyze(), MuonIdVal::analyze(), MCvsRecoVerticesAnalyzer::analyze(), EGammaCutBasedEleIdAnalyzer::analyze(), L1JetRecoTreeProducer::analyze(), L1TGT::analyze(), DTDataIntegrityTask::analyze(), L1Validator::analyze(), l1t::GtRecordDump::analyze(), SiPixelErrorsDigisToCalibDigis::analyze(), SiPixelClusterSource::analyze(), HLTGetDigi::analyze(), HLTHeavyIon::analyze(), SiStripFEDMonitorPlugin::analyze(), FFTJetPileupAnalyzer::analyze(), HGCalRecHitValidation::analyze(), FSQDiJetAve::analyze(), APVCyclePhaseDebuggerFromL1TS::analyze(), MultiplicityTimeCorrelations::analyze(), OverlapProblemTPAnalyzer::analyze(), TauJetCorrectorExample::analyze(), L1TCSCTF::analyze(), L1TRPCTPG::analyze(), CosmicSplitterValidation::analyze(), L1TComparison::analyze(), TestCorrection::analyze(), L1TdeCSCTF::analyze(), SiPixelErrorEstimation::analyze(), PhotonValidator::analyze(), AnalyzerMinbias::analyze(), HcalHBHEMuonAnalyzer::analyze(), MuonIsolationDQM::analyze(), L1CaloTowerTreeProducer::analyze(), L1TauRecoTreeProducer::analyze(), DuplicateRecHits::analyze(), HLTOfflineReproducibility::analyze(), TrackCount::analyze(), JetMETHLTOfflineSource::analyze(), HLTriggerJSONMonitoring::analyze(), HcalDigisValidation::analyze(), MuIsoValidation::analyze(), OccupancyPlots::analyze(), OverlapProblemTSOSAnalyzer::analyze(), DTTriggerEfficiencyTask::analyze(), SiStripCMMonitorPlugin::analyze(), HLTScalers::analyze(), ValidIsoTrkCalib::analyze(), HLTHiggsSubAnalysis::analyze(), HLTMuonPlotter::analyze(), IsoTrig::analyze(), HcalIsoTrkAnalyzer::analyze(), SiPixelTrackingRecHitsValid::analyze(), HcalDigiMonitor::analyze(), GenPurposeSkimmerData::analyze(), JetTester_HeavyIons::analyze(), L1TriggerJSONMonitoring::analyze(), MuonAlignment::analyze(), L1TCompare::analyze(), APVShotsAnalyzer::analyze(), TauTagValidation::analyze(), GlobalHitsHistogrammer::analyze(), IsoTrackCalibration::analyze(), HGCalSimHitValidation::analyze(), ValidationHcalIsoTrackAlCaReco::analyze(), HcalTimingMonitorModule::analyze(), PiZeroAnalyzer::analyze(), pat::CandidateSummaryTable::analyze(), L1Muon2RecoTreeProducer::analyze(), DiJetAnalyzer::analyze(), CastorMonitorModule::analyze(), JetAnalyzer_HeavyIons_matching::analyze(), IsoTrackCalib::analyze(), JetAnalyzer_HeavyIons::analyze(), DTLocalTriggerTask::analyze(), EcalMixingModuleValidation::analyze(), L1TSync::analyze(), CosmicRateAnalyzer::analyze(), IsolatedGenParticles::analyze(), ExoticaDQM::analyze(), SeedMultiplicityAnalyzer::analyze(), JetAnalyzer::analyze(), analyzer::SiPixelLorentzAngle::analyze(), ErsatzMEt::analyze(), TriggerJSONMonitoring::analyze(), HLTObjectMonitor::analyze(), RPCEfficiency::analyze(), SiStripSpyDisplayModule::analyze(), V0Validator::analyze(), ZToMuMuGammaAnalyzer::analyze(), PhotonAnalyzer::analyze(), IsolatedTracksCone::analyze(), PCLTrackerAlProducer::analyze(), HcalDetDiagTimingMonitor::analyze(), L1TSync_Offline::analyze(), METAnalyzer::analyze(), HcalDetDiagLEDMonitor::analyze(), L1TBPTX::analyze(), IsolatedTracksHcalScale::analyze(), IsolatedTracksNxN::analyze(), SiStripRecHitsValid::analyze(), GammaJetAnalysis::analyze(), TrackerDpgAnalysis::analyze(), CSCMonitorModule::analyze(), PrimaryVertexAnalyzer4PUSlimmed::analyze(), L1TGCT::analyze(), L1TEfficiencyMuons_Offline::analyze(), MuonTrackValidator::analyze(), SiPixelOfflineCalibAnalysisBase::analyze(), ApeEstimator::analyze(), BeamHaloAnalyzer::analyze(), HcalDetDiagPedestalMonitor::analyze(), TopSingleLeptonDQM_miniAOD::analyze(), HOCalibAnalyzer::analyze(), SingleTopTChannelLeptonDQM_miniAOD::analyze(), TopSingleLeptonHLTOfflineDQM::analyze(), SiStripTrackingRecHitsValid::analyze(), TopDiLeptonHLTOfflineDQM::analyze(), TopSingleLeptonDQM::analyze(), HcalDetDiagLaserMonitor::analyze(), SingleTopTChannelLeptonDQM::analyze(), TopDiLeptonOfflineDQM::analyze(), PackedCandidateTrackValidator::analyze(), B2GDQM::analyzeAllHad(), L1GtAnalyzer::analyzeConditionsInEventBlock(), L1GtAnalyzer::analyzeDecisionReadoutRecord(), ExoticaDQM::analyzeDiJets(), EgammaObjects::analyzeElectrons(), B2GDQM::analyzeJets(), L1ExtraDQM::analyzeL1ExtraIsoTauJet(), L1GtAnalyzer::analyzeObjectMap(), EgammaObjects::analyzePhotons(), B2GDQM::analyzeSemiE(), B2GDQM::analyzeSemiMu(), L1GtAnalyzer::analyzeTrigger(), FFTJetCorrectionProducer::applyCorrections(), SegmentsTrackAssociator::associate(), MuonCosmicCompatibilityFiller::backToBack2LegCosmic(), RecoTauDecayModeCutMultiplexer::beginEvent(), reco::tau::RecoTauDiscriminantCleanerPlugin::beginEvent(), reco::tau::RecoTauTagInfoWorkaroundModifer::beginEvent(), ecaldqm::ClusterTask::beginEvent(), MuPFIsoHelper::beginEvent(), RecoTauDiscriminantCutMultiplexer::beginEvent(), PFTauDecayModeCutMultiplexer::beginEvent(), PFRecoTauDiscriminationAgainstElectronMVA6::beginEvent(), PFRecoTauDiscriminationAgainstElectronMVA5::beginEvent(), reco::tau::RecoTauBuilderPlugin::beginEvent(), PFRecoTauDiscriminationByIsolationMVA2::beginEvent(), PFRecoTauDiscriminationByMVAIsolationRun2::beginEvent(), TtFullLepHypKinSolution::buildHypo(), TtFullHadHypGenMatch::buildHypo(), TtFullLepHypGenMatch::buildHypo(), TtSemiLepHypGenMatch::buildHypo(), TtSemiLepHypHitFit::buildHypo(), TtSemiLepHypKinFit::buildHypo(), TtFullHadHypKinFit::buildHypo(), TtFullLepHypGenMatch::buildMatchingNeutrinos(), ConversionProducer::buildSuperAndBasicClusterGeoMap(), pat::LeptonJetIsolationAngle::calculate(), pat::LeptonVertexSignificance::calculate(), PhotonIsolationCalculator::calculateEcalRecHitIso(), PhotonIsolationCalculator::calculateHcalTowerIso(), PhotonIsolationCalculator::calculateTrackIso(), MuonDetLayerMeasurements::checkCSCRecHits(), MuonDetLayerMeasurements::checkDTRecHits(), MuonDetLayerMeasurements::checkGEMRecHits(), AlignmentGlobalTrackSelector::checkIsolation(), AlignmentGlobalTrackSelector::checkJetCount(), MuonDetLayerMeasurements::checkME0RecHits(), AlignmentTwoBodyDecayTrackSelector::checkMETMass(), AlignmentTrackSelector::checkPrescaledHits(), MuonDetLayerMeasurements::checkRPCRecHits(), SiStripAnalyser::checkTrackerFEDs(), CutBasedElectronID::cicSelection(), ctfseeding::HitExtractorSTRP::cleanedOfClusters(), CosmicClusterProducer::clusterizeECALPart(), Digi2Raw2Digi::compare(), L1GtHwValidation::compareDaqRecord(), L1GtHwValidation::compareEvmRecord(), METCorrectionAlgorithm::compMETCorrection(), RazorComputer::compute(), L1BitComputer::compute(), HLTBitComputer::compute(), HLTDoubletDZ< T1, T2 >::computeDZ(), reco::PFMETProducerMVA::computeLeptonInfo(), SiStripGainFromCalibTree::connect(), PFClusterEMEnergyCorrector::correctEnergies(), FSQ::HandlerTemplate< TInputCandidateType, TOutputCandidateType, filter >::count(), egammaisolation::EgammaRecHitExtractor::deposit(), egammaisolation::EgammaHcalExtractor::deposit(), egammaisolation::EgammaEcalExtractor::deposit(), egammaisolation::EgammaTowerExtractor::deposit(), PFTauExtractor::depositFromObject(), FFTJetProducer::determinePileupDensityFromConfig(), FFTJetProducer::determinePileupDensityFromDB(), SiStripFineDelayHit::detId(), RPCTTUMonitor::discriminateGMT(), CSCOfflineMonitor::doBXMonitor(), HLTTauRefProducer::doElectrons(), HLTTauRefProducer::doJets(), HLTTauRefProducer::doMET(), HLTTauRefProducer::doMuons(), HLTTauRefProducer::doPFTaus(), HLTTauRefProducer::doPhotons(), Tau3MuReco::doTau3MuReco(), HLTTauRefProducer::doTowers(), EcalListOfFEDSProducer::Egamma(), ESListOfFEDSProducer::Egamma(), HITrackingRegionProducer::estimateMultiplicity(), HITrackingRegionForPrimaryVtxProducer::estimateMultiplicity(), HLTBitVariable::eval(), ExpressionVariable< Object, label >::eval(), SimpleValueVariable< TYPE >::eval(), SimpleValueVectorVariable< TYPE >::eval(), MuonCosmicCompatibilityFiller::eventActivity(), PSimHitMap::fill(), DigiVtxPosCorrHistogramMaker::fill(), DigiPileupCorrHistogramMaker::fill(), SingleTopTChannelLepton_miniAOD::MonitorEnsemble::fill(), TopSingleLepton_miniAOD::MonitorEnsemble::fill(), HLTOfflineDQMTopSingleLepton::MonitorSingleLepton::fill(), HcalSignalGenerator< HBHEDigitizerTraits >::fill(), HLTOfflineDQMTopDiLepton::MonitorDiLepton::fill(), SiPixelCalibDigiProducer::fill(), TopSingleLepton::MonitorEnsemble::fill(), SingleTopTChannelLepton::MonitorEnsemble::fill(), TopDiLeptonOffline::MonitorEnsemble::fill(), TauDiscriminationProducerBase< TauType, TauDiscriminator >::TauDiscInfo::fill(), EcalSignalGenerator< EEDigitizerTraits >::fill(), TrackDetectorAssociator::fillCaloTowers(), TrackDetectorAssociator::fillCaloTruth(), reco::HcalNoiseInfoProducer::fillcalotwrs(), reco::HcalNoiseInfoProducer::filldigis(), MuonSimHitsValidAnalyzer::fillDT(), GlobalHitsProdHist::fillECal(), GlobalHitsAnalyzer::fillECal(), GlobalHitsProducer::fillECal(), GlobalDigisProducer::fillECal(), GlobalDigisAnalyzer::fillECal(), TrackDetectorAssociator::fillEcal(), GlobalRecHitsAnalyzer::fillECal(), GlobalRecHitsProducer::fillECal(), TrackerHitProducer::fillG4MC(), GlobalHitsProdHist::fillG4MC(), GlobalHitsAnalyzer::fillG4MC(), GlobalHitsProducer::fillG4MC(), GlobalHitsProdHist::fillHCal(), GlobalHitsAnalyzer::fillHCal(), GlobalHitsProducer::fillHCal(), GlobalDigisProducer::fillHCal(), GlobalDigisAnalyzer::fillHCal(), TrackDetectorAssociator::fillHcal(), GlobalRecHitsAnalyzer::fillHCal(), GlobalRecHitsProducer::fillHCal(), HistoFillerReco< T >::fillHistos(), TrackDetectorAssociator::fillHO(), AlCaHOCalibProducer::fillHOStore(), reco::HcalNoiseInfoProducer::filljetinfo(), JetMETHLTOfflineSource::fillMEforMonTriggerSummary(), METAnalyzer::fillMonitorElement(), GlobalHitsProdHist::fillMuon(), GlobalHitsAnalyzer::fillMuon(), GlobalHitsProducer::fillMuon(), GlobalDigisProducer::fillMuon(), GlobalDigisAnalyzer::fillMuon(), TrackDetectorAssociator::fillMuon(), GlobalRecHitsAnalyzer::fillMuon(), GlobalRecHitsProducer::fillMuon(), DTTFFEDSim::fillRawData(), L1TTwinMuxRawToDigi::fillRawData(), RCTMonitor::FillRCT(), reco::HcalNoiseInfoProducer::fillrechits(), HcalRecHitsAnalyzer::fillRecHitsTmp(), HcalRecHitsValidation::fillRecHitsTmp(), TtEvtBuilder< C >::fillSpecific(), reco::HcalNoiseInfoProducer::filltracks(), TrackerHitProducer::fillTrk(), GlobalHitsProdHist::fillTrk(), GlobalHitsAnalyzer::fillTrk(), GlobalHitsProducer::fillTrk(), GlobalDigisProducer::fillTrk(), GlobalDigisAnalyzer::fillTrk(), GlobalRecHitsAnalyzer::fillTrk(), GlobalRecHitsProducer::fillTrk(), PdfSystematicsAnalyzer::filter(), SimpleSystematicsAnalyzer::filter(), DetStatus::filter(), DetectorStateFilter::filter(), ZtoMMEventSelector::filter(), ZToMuMuFilter::filter(), ZToMuMuSelector::filter(), LaserAlignmentEventFilter::filter(), CandCollectionExistFilter::filter(), EcalMonitorPrescaler::filter(), TopDecayChannelFilter< S >::filter(), CSCTightHalo2015Filter::filter(), CSCTightHaloFilter::filter(), CSCTightHaloTrkMuUnvetoFilter::filter(), GlobalSuperTightHalo2016Filter::filter(), GlobalTightHalo2016Filter::filter(), ZtoEEEventSelector::filter(), HcalStripHaloFilter::filter(), EENoiseFilter::filter(), HcalTBTriggerFilter::filter(), ClusterMultiplicityFilter::filter(), JetIDFailureFilter::filter(), TrackingFailureFilter::filter(), PFJetFilter::filter(), HLTPathSelector::filter(), HSCParticleSelector::filter(), EvtPlaneFilter::filter(), WtoLNuSelector::filter(), DTCalibMuonSelection::filter(), HLTHcalMETNoiseCleaner::filter(), HLTHPDFilter::filter(), HLTRPCFilter::filter(), TauSpinnerFilter::filter(), HLTHcalLaserFilter::filter(), WMuNuValidator::filter(), PythiaFilterGammaGamma::filter(), HLTHcalMETNoiseFilter::filter(), JetMETDQMDCSFilter::filter(), ElectronIdMVAProducer::filter(), PhotonIsoProducer::filter(), pat::PATLeptonCountFilter::filter(), BCToEFilterAlgo::filter(), PythiaFilterMultiMother::filter(), HLTPhysicsDeclared::filter(), HSCPHLTFilter::filter(), EMEnrichingFilterAlgo::filter(), CentralityFilter::filter(), GreedyMuonPFCandidateFilter::filter(), JetFlavourCutFilter::filter(), JetFlavourFilter::filter(), PythiaFilterEMJet::filter(), VBFGenJetFilter::filter(), ChargedHadronTrackResolutionFilter::filter(), StringCutObjectEvtFilter< T >::filter(), ProbeTreeProducer::filter(), PythiaFilterZgamma::filter(), InconsistentMuonPFCandidateFilter::filter(), MuonBadTrackFilter::filter(), edm::ModelFilter::filter(), pat::PATSingleVertexSelector::filter(), BdecayFilter::filter(), BsJpsiPhiFilter::filter(), PythiaFilterGammaJet::filter(), PythiaFilterGammaJetIsoPi0::filter(), PythiaFilterGammaJetWithBg::filter(), PythiaFilterGammaJetWithOutBg::filter(), PythiaFilterZJet::filter(), PythiaFilterZJetWithOutBg::filter(), ElectronRegressionEnergyProducer::filter(), SiStripCommissioningSeedFilter::filter(), HLTRHemisphere::filter(), EFilter::filter(), SiStripCommissioningRunTypeFilter::filter(), HLTPixelActivityHFSumEnergyFilter::filter(), EgammaProbeSelector::filter(), WMuNuSelector::filter(), HeavyChHiggsToTauNuSkim::filter(), EcalLaserCorrFilter::filter(), ObjectPairFilter< C, S >::filter(), PythiaFilterEMJetHeep::filter(), FilterOutScraping::filter(), LogErrorEventFilter::filter(), PythiaFilterIsolatedTrack::filter(), PhysDecl::filter(), CSCDigiValidator::filter(), LogErrorFilter::filter(), BooleanFlagFilter::filter(), ErrorSummaryFilter::filter(), HighMultiplicityGenFilter::filter(), RecoTauPileUpVertexSelector::filter(), GenHTFilter::filter(), LHEGenericFilter::filter(), MCSmartSingleParticleFilter::filter(), SiPixelCalibDigiFilter::filter(), pat::PATJetSelector::filter(), CosmicGenFilterHelix::filter(), CastorInvalidDataFilter::filter(), HLTHighLevel::filter(), GoodVertexFilter::filter(), HLTL1NumberFilter::filter(), MCDecayingPionKaonFilter::filter(), MCDijetResonance::filter(), MCZll::filter(), AlCaIsolatedBunchFilter::filter(), AlCaIsolatedBunchSelector::filter(), DJpsiFilter::filter(), FourLepFilter::filter(), HZZ4lFilter::filter(), MCParticlePairFilter::filter(), MCProcessRangeFilter::filter(), MCSingleParticleFilter::filter(), PythiaDauFilter::filter(), PythiaDauVFilter::filter(), PythiaFilter::filter(), PythiaHLTSoupFilter::filter(), ZgMassFilter::filter(), EEBadScFilter::filter(), BVertexFilterT< VTX >::filter(), MCProcessFilter::filter(), ZgammaMassFilter::filter(), MonoPhotonSkimmer::filter(), HLTHcalCalibTypeFilter::filter(), HFFilter::filter(), HcalEmptyEventFilter::filter(), edm::FwdPtrCollectionFilter< T, S, H >::filter(), HcalCalibTypeFilter::filter(), HerwigMaxPtPartonFilter::filter(), PrescalerFHN::filter(), L1TValidationEventFilter::filter(), TMTFilter::filter(), JetConstituentSelector< T, C >::filter(), SiStripDetWithSomething< T >::filter(), JetVertexChecker::filter(), MCVerticesWeight::filter(), HLTHFAsymmetryFilter::filter(), FEDBadModuleFilter::filter(), HiCentralityBiasFilter::filter(), HcalLaserEventFilter::filter(), HSCPFilter::filter(), AlCaHBHEMuonFilter::filter(), HcalLaserHBHEFilter2012::filter(), HcalLaserHBHEHFFilter2012::filter(), HcalLaserHFFilter2012::filter(), PythiaFilterTTBar::filter(), LargeEvents< T >::filter(), HLTPrescaler::filter(), HSCParticleProducer::filter(), ObjectSelector< SingleElementCollectionSelector< InputCollection, Selector, reco::CandidateCollection, StoreContainer, RefAdder >, reco::CandidateCollection, NonNullNumberSelector >::filter(), SiStripShotFilter::filter(), ElectronIdFilter::filter(), aod2patFilterZee::filter(), APVShotsFilter::filter(), EcalDeadCellBoundaryEnergyFilter::filter(), FFTJetDijetFilter::filter(), OverlapProblemTSOSPositionFilter::filter(), edm::HadronizerFilter< HAD, DEC >::filter(), ElectronIdMVABased::filter(), AlCaIsoTracksFilter::filter(), HLTEcalResonanceFilter::filter(), HLTRegionalEcalResonanceFilter::filter(), FlavorHistoryFilter::filter(), ZeeCandidateFilter::filter(), HSCPTreeBuilder::filter(), pat::PATSingleVertexSelector::filter_(), SiStripClusterizer::findInput(), SiStripProcessedRawDigiProducer::findInput(), AlignmentGlobalTrackSelector::findMuons(), OMTFPatternMaker::findSimMuon(), V0Fitter::fitAll(), RPCPhiEff::fromRaw(), GEMDigiMatcher::GEMDigiMatcher(), GEMRecHitMatcher::GEMRecHitMatcher(), RunManagerMTWorker::generateEvent(), FFTJetProducer::genJetPreclusters(), EventWithHistoryFilter::getAPVPhase(), L1TSync_Offline::getBeamConfOffline(), MatacqProducer::getCalibTriggerType(), Multi5x5SuperClusterProducer::getClusterPtrVector(), HiSuperClusterProducer::getClusterPtrVector(), Multi5x5ClusterProducer::getCollection(), EgammaHLTMulti5x5ClusterProducer::getCollection(), IslandClusterProducer::getCollection(), EgammaHLTIslandClusterProducer::getCollection(), HLTDoubletDZ< T1, T2 >::getCollections(), AddCorrectionsToGenericMET::getCorrection(), JetMatchingTools::getEBRecHitCollection(), EcalClusterLazyToolsBase::getEBRecHits(), JetMatchingTools::getEBSimHitCollection(), JetMatchingTools::getEERecHitCollection(), EcalClusterLazyToolsBase::getEERecHits(), JetMatchingTools::getEESimHitCollection(), pat::PATMHTProducer::getElectrons(), EcalClusterLazyToolsBase::getESRecHits(), ClusterSummarySingleMultiplicity::getEvent(), SingleMultiplicity< T >::getEvent(), ElectronPFIsolationWithMapBasedVeto::getEventInfo(), PhotonPFIsolationWithMapBasedVeto::getEventInfo(), FSQ::HandlerTemplate< TInputCandidateType, TOutputCandidateType, filter >::getFilteredCands(), DAFTrackProducer::getFromEvt(), JetMatchingTools::getGenParticlesCollection(), IsoTrig::getGoodTracks(), HLTExoticaSubAnalysis::getHandlesToObjects(), JetMatchingTools::getHBHERecHitCollection(), JetMatchingTools::getHcalSimHitCollection(), JetMatchingTools::getHFRecHitCollection(), JetMatchingTools::getHORecHitCollection(), MeasurementTrackerEventProducer::getInactiveStrips(), PFCand_AssoMapAlgos::GetInputCollections(), PF_PU_AssoMapAlgos::GetInputCollections(), pat::PATMHTProducer::getJets(), pat::PATMHTProducer::getMuons(), MatacqProducer::getOrbitId(), HLTEgammaDoubleLegCombFilter::getP3OfLegCands(), HLTEgammaAllCombMassFilter::getP4OfLegCands(), HLTEgammaCombMassFilter::getP4OfLegCands(), MixEvtVtxGenerator::getRecVertex(), MixBoostEvtVtxGenerator::getRecVertex(), JetMatchingTools::getSimTrackCollection(), KVFTest::getSimVertex(), KineExample::getSimVertex(), JetMatchingTools::getSimVertexCollection(), SiStripDCSStatus::getStatus(), MixEvtVtxGenerator::getVertex(), MixBoostEvtVtxGenerator::getVertex(), DTTriggerEfficiencyTask::hasRPCTriggers(), Vx3DHLTAnalyzer::HitCounter(), CombinedHitQuadrupletGeneratorForPhotonConversion::hitPairs(), CombinedHitPairGenerator::hitPairs(), CombinedHitPairGeneratorForPhotonConversion::hitPairs(), ctfseeding::HitExtractorPIX::hits(), ctfseeding::HitExtractorSTRP::hits(), CombinedMultiHitGenerator::hitSets(), PixelTripletLowPtGenerator::hitTriplets(), CombinedHitTripletGenerator::hitTriplets(), HLTEcalIsolationFilter::hltFilter(), HLTDiMuonGlbTrkFilter::hltFilter(), HLTPixelIsolTrackFilter::hltFilter(), HLTmumutkFilter::hltFilter(), HLTDisplacedtktkFilter::hltFilter(), HLTDisplacedmumuFilter::hltFilter(), HLTmumutktkFilter::hltFilter(), HLTPixelIsolTrackL1TFilter::hltFilter(), HLTMuonTrkFilter::hltFilter(), HLTMuonTrkL1TFilter::hltFilter(), HLTDisplacedmumumuFilter::hltFilter(), HLTEcalPixelIsolTrackFilter::hltFilter(), HLTElectronMissingHitsFilter::hltFilter(), HLTCSCOverlapFilter::hltFilter(), HLTCSCRing2or3Filter::hltFilter(), HLTHcalNoiseFilter::hltFilter(), HLTElectronPixelMatchFilter::hltFilter(), HLTNVFilter::hltFilter(), HLTPhi2METFilter::hltFilter(), HLTRapGapFilter::hltFilter(), HLTHemiDPhiFilter::hltFilter(), HLTMuonTrackMassFilter::hltFilter(), HLTForwardBackwardJetsFilter< T >::hltFilter(), HLTMuonL1RegionalFilter::hltFilter(), HLTMuonL1TFilter::hltFilter(), HLTSingleVertexPixelTrackFilter::hltFilter(), HLTJetPairDzMatchFilter< T >::hltFilter(), HLT2jetGapFilter::hltFilter(), HLTJetCollectionsFilter< jetType >::hltFilter(), HLTPFTauPairLeadTrackDzMatchFilter::hltFilter(), HLTEgammaDoubleEtDeltaPhiFilter::hltFilter(), HLTEgammaEtFilter::hltFilter(), HLTEgammaEtFilterPairs::hltFilter(), HLTElectronEtFilter::hltFilter(), HLTMuonL1TRegionalFilter::hltFilter(), HLTEgammaGenericQuadraticEtaFilter::hltFilter(), HLTEgammaGenericQuadraticFilter::hltFilter(), HLTEgammaTriggerFilterObjectWrapper::hltFilter(), HLTElectronEoverpFilterRegional::hltFilter(), HLTElectronGenericFilter::hltFilter(), HLTElectronOneOEMinusOneOPFilterRegional::hltFilter(), HLTMuonDimuonL3Filter::hltFilter(), HLTDeDxFilter::hltFilter(), HLTDisplacedEgammaFilter::hltFilter(), HLTDiJetAveEtaFilter< T >::hltFilter(), HLTMuonTrimuonL3Filter::hltFilter(), HLTDiJetAveFilter< T >::hltFilter(), HLTDiJetEtaTopologyFilter< T >::hltFilter(), HLTJetEtaTopologyFilter< T >::hltFilter(), HLTJetVBFFilter< T >::hltFilter(), HLTMonoJetFilter< T >::hltFilter(), HLTMuonDimuonL2Filter::hltFilter(), HLTMuonDimuonL2FromL1TFilter::hltFilter(), HLTMuonL2FromL1TPreFilter::hltFilter(), HLTMuonL2PreFilter::hltFilter(), HLTMuonPFIsoFilter::hltFilter(), HLTPMDocaFilter::hltFilter(), HLTExclDiJetFilter< T >::hltFilter(), HLTFatJetMassFilter< jetType >::hltFilter(), HLTJetCollectionsVBFFilter< T >::hltFilter(), HLTMuonIsoFilter::hltFilter(), HLTEgammaDoubleEtFilter::hltFilter(), HLTEgammaDoubleEtPhiFilter::hltFilter(), HLTEgammaL1MatchFilterPairs::hltFilter(), HLTEgammaL1MatchFilterRegional::hltFilter(), HLTMhtFilter::hltFilter(), HLTMuonL1toL3TkPreFilter::hltFilter(), HLTMuonL3PreFilter::hltFilter(), HLTEgammaL1TMatchFilterRegional::hltFilter(), HLTSinglet< T >::hltFilter(), HLTAcoFilter::hltFilter(), HLTMuonL1TtoL3TkPreFilter::hltFilter(), HLTEgammaCaloIsolFilterPairs::hltFilter(), HLTGlobalSums< T >::hltFilter(), HLTAlphaTFilter< T >::hltFilter(), HLTPixlMBFilt::hltFilter(), HLTPixlMBForAlignmentFilter::hltFilter(), HLTRFilter::hltFilter(), HLTHtMhtFilter::hltFilter(), HLTMinDPhiMETFilter::hltFilter(), HLTMuonL1Filter::hltFilter(), HLTSmartSinglet< T >::hltFilter(), HLTSummaryFilter::hltFilter(), HLTPFEnergyFractionsFilter::hltFilter(), HLTElectronPFMTFilter< T >::hltFilter(), HLTDoublet< T1, T2 >::hltFilter(), HLTFiltCand::hltFilter(), HLTElectronMuonInvMassFilter::hltFilter(), HLTGenericFilter< T1 >::hltFilter(), HLTHcalPhiSymFilter::hltFilter(), HLTFEDSizeFilter::hltFilter(), HLTHcalNZSFilter::hltFilter(), HLTHcalSimpleRecHitFilter::hltFilter(), HLTmmkkFilter::hltFilter(), HLTmmkFilter::hltFilter(), HLTCountNumberOfObject< OColl >::hltFilter(), HLTCSCActivityFilter::hltFilter(), HLTCSCAcceptBusyFilter::hltFilter(), HLTBeamModeFilter::hltFilter(), HLTTrackWithHits::hltFilter(), HLTCAWZTagFilter::hltFilter(), HLTPMMassFilter::hltFilter(), HLTCATopTagFilter::hltFilter(), HLTDTActivityFilter::hltFilter(), HLTRPCTrigNoSyncFilter::hltFilter(), HLTLevel1GTSeed::hltFilter(), HLTMuonL2ToL1Map::HLTMuonL2ToL1Map(), HLTMuonL2ToL1TMap::HLTMuonL2ToL1TMap(), PFHBHERecHitCreator::importRecHits(), PFHcalRecHitCreator< Digi, Geometry, Layer, Detector >::importRecHits(), PFHGCalRecHitCreator< DET, Layer, subdet >::importRecHits(), PFEcalRecHitCreatorMaxSample< Geometry, Layer, Detector >::importRecHits(), PFEcalRecHitCreator< Geometry, Layer, Detector >::importRecHits(), PFPSRecHitCreator::importRecHits(), PFHFRecHitCreator::importRecHits(), PFHBHERecHitCreatorMaxSample::importRecHits(), GenericClusterImporter::importToBlock(), EGPhotonImporter::importToBlock(), ECALClusterImporter::importToBlock(), GSFTrackImporter::importToBlock(), SuperClusterImporter::importToBlock(), GeneralTracksImporter::importToBlock(), pflow::importers::TrackFromParentImporter< Collection, Adaptor >::importToBlock(), TrackCollectionTokens::indicesInput(), LowPtClusterShapeSeedComparitor::init(), PixelClusterShapeSeedComparitor::init(), tnp::ProbeVariable::init(), MuonIdProducer::init(), tnp::ProbeFlag::init(), tnp::BaseTreeFiller::init(), HLTHiggsSubAnalysis::initAndInsertJets(), muonisolation::CandViewExtractor::initEvent(), SiStripDCSStatus::initialise(), HLTHiggsSubAnalysis::initobjects(), CosmicSplitterValidation::is_gold_muon(), AlignmentTrackSelector::isIsolated(), MuonCosmicCompatibilityFiller::isOverlappingMuon(), EcalListOfFEDSProducer::Jets(), ESListOfFEDSProducer::Jets(), L1GtUtils::l1Results(), PFECALSuperClusterAlgo::loadAndSortPFClusters(), EcalDeadCellTriggerPrimitiveFilter::loadEcalDigis(), EcalDeadCellTriggerPrimitiveFilter::loadEcalRecHits(), FFTJetProducer::loadEnergyFlow(), fftjetcms::FFTJetInterface::loadInputCollection(), EcalDeadCellDeltaRFilter::loadJets(), EcalDeadCellDeltaRFilter::loadMET(), FFTJetProducer::loadSparseTreeData(), PhotonConversionTrajectorySeedProducerFromSingleLegAlgo::loopOnTracks(), L1FastjetCorrectorImplMaker::make(), L1OffsetCorrectorImplMaker::make(), L1JPTOffsetCorrectorImplMaker::make(), L6SLBCorrectorImplMaker::make(), shallow::make_cluster_map(), IPProducerHelpers::FromJTA::makeBaseVector(), IPProducerHelpers::FromJetAndCands::makeBaseVector(), RPCRecHitProbability::makeDcsInfo(), RPCDcsInfo::makeDcsInfo(), DQMDcsInfo::makeDcsInfo(), HSCPValidator::makeGenPlots(), DQMDcsInfo::makeGtInfo(), HSCPValidator::makeHLTPlots(), DQMScalInfo::makeL1Scalars(), DQMScalInfo::makeLumiScalars(), TrackerHitAssociator::makeMaps(), HSCPValidator::makeRecoPlots(), HSCPValidator::makeSimDigiPlotsECAL(), HSCPValidator::makeSimDigiPlotsRPC(), HSCPValidator::makeSimTrackPlots(), DQMExample_Step1::MediumEle(), SiStripZeroSuppression::MergeCollectionsZeroSuppression(), PhotonMIPHaloTagger::MIPcalculate(), EcalListOfFEDSProducer::Muon(), ESListOfFEDSProducer::Muon(), MuonCosmicCompatibilityFiller::muonTiming(), OverlapExclusionSelector< C, T, O >::newEvent(), reco::modules::MCMatchCandRefSelector::newEvent(), pat::helper::EfficiencyLoader::newEvent(), ZGoldenFilter::newEvent(), pat::helper::VertexingHelper::newEvent(), MuonCosmicCompatibilityFiller::nMuons(), TwoObjectVariable< LHS, lLHS, RHS, lRHS, Calculator >::objects(), PFCandIsolatorFromDeposits::SingleDeposit::open(), CandIsolatorFromDeposits::SingleDeposit::open(), TtDilepLRSignalSelObservables::operator()(), ElectronIDSelectorLikelihood::operator()(), ObjectCountEventSelector< edm::View, AnySelector, MinNumberSelector >::operator()(), TtSemiLRJetCombObservables::operator()(), reco::tau::PFRecoTauChargedHadronFromTrackPlugin::operator()(), MCPdgIndexFilter::pass(), SeedMultiplicityAnalyzer::FromTrackRefSeedFilter::prepareEvent(), L1GtUtils::prescaleFactorSetIndex(), HcalSimpleReconstructor::process(), DTTFFEDReader::process(), StandaloneTrackMonitor::processClusters(), HcalRecHitMonitor::processEvent(), MultiTrackSelector::processMVA(), HIMultiTrackSelector::processMVA(), FFTJetTreeDump::processTreeData(), HcalSimpleReconstructor::processUpgrade(), DimuonMCMatcher::produce(), WeakEffectsWeightProducer::produce(), TtGenEventReco::produce(), ShallowEventDataProducer::produce(), MaskedMeasurementTrackerEventProducer::produce(), StGenEventReco::produce(), SiStripRecHitConverter::produce(), PatElectronEAIsoCorrectionProducer::produce(), FixedGridRhoProducer::produce(), SeedGeneratorFromProtoTracksEDProducer::produce(), HIBestVertexProducer::produce(), HIPixelMedianVtxProducer::produce(), ShallowTracksProducer::produce(), InterestingEcalDetIdProducer::produce(), HcalTTPTriggerRecord::produce(), QualityFilter::produce(), HcalTTPDigiProducer::produce(), HFEMClusterProducer::produce(), BasicToPFJet::produce(), CastorSimpleReconstructor::produce(), PixelVertexProducerClusters::produce(), RazorVarProducer::produce(), CastorTTRecord::produce(), JetChargeProducer::produce(), TrackingParticleConversionSelector::produce(), SeedCombiner::produce(), ConversionTrackRefFix::produce(), ECFAdder::produce(), FixedGridRhoProducerFastjet::produce(), HcalLaserReco::produce(), reco::modules::CaloRecHitCandidateProducer< HitCollection >::produce(), HGCalUncalibRecHitProducer::produce(), TrackListCombiner::produce(), MuonSelectorVertex::produce(), AlphaTVarProducer::produce(), TtSemiLepJetCombMaxSumPtWMass::produce(), GenParticleDecaySelector::produce(), MassKinFitterCandProducer::produce(), ShallowRechitClustersProducer::produce(), EgammaHLTTimeCleanedRechitProducer::produce(), HcalTrigPrimDigiProducer::produce(), ElectronSeedMerger::produce(), TrackingParticleNumberOfLayersProducer::produce(), TopInitSubset::produce(), TtSemiLepJetCombGeom::produce(), TtSemiLepJetCombWMassMaxSumPt::produce(), DistortedMETProducer::produce(), EventVtxInfoNtupleDumper::produce(), DTDigiToRawModule::produce(), CSCTFCandidateProducer::produce(), GeneratorSmearedProducer::produce(), QGTagger::produce(), CosmicMuonProducer::produce(), GsfTrackRefitter::produce(), ParticleDecayProducer::produce(), CSCDigiProducer::produce(), TrackRefitter::produce(), MCTruthCompositeMatcher< C1, C2 >::produce(), pat::PATVertexSlimmer::produce(), UnifiedSCCollectionProducer::produce(), CosmicMuonLinksProducer::produce(), ShallowSimhitClustersProducer::produce(), ShallowTrackClustersProducer::produce(), CRackSeedGenerator::produce(), DQMTauProducer::produce(), PFJetToCaloProducer::produce(), PFTauToJetProducer::produce(), CandPtrProjector::produce(), TtSemiLepKinFitProducer< LeptonCollection >::produce(), StEvtSolutionMaker::produce(), TtDilepEvtSolutionMaker::produce(), CalibratedPhotonProducerRun2T< T >::produce(), MuonWithPFIsoProducer::produce(), pat::PATSecondaryVertexSlimmer::produce(), AssociationMapOneToOne2Association< CKey, CVal >::produce(), AssociationVectorSelector< KeyRefProd, CVal, KeySelector, ValSelector >::produce(), ESRawToDigi::produce(), SiStripElectronSeedProducer::produce(), PhotonIDProducer::produce(), EcalUncalibRecHitProducer::produce(), ESRecHitProducer::produce(), MuonTrackProducer::produce(), DiJetVarProducer::produce(), CaloTowersReCreator::produce(), TtSemiLepJetCombWMassDeltaTopMass::produce(), CandOneToOneDeltaRMatcher::produce(), DistortedMuonProducerFromDB::produce(), DistortedPFCandProducer::produce(), pat::PATMETSlimmer::produce(), HcalRealisticZS::produce(), QuarkoniaTrackSelector::produce(), AssociationVector2ValueMap< KeyRefProd, CVal >::produce(), UncleanSCRecoveryProducer::produce(), RawDataCollectorByLabel::produce(), JetTracksAssociatorExplicit::produce(), EcalRecalibRecHitProducer::produce(), CandOneToManyDeltaRMatcher::produce(), JetTracksAssociatorAtVertex::produce(), L2TauJetsMerger::produce(), VertexAssociatorByTracksProducer::produce(), CandViewRefMerger::produce(), VertexAssociatorByPositionAndTracksProducer::produce(), JetExtender::produce(), HcalSimpleAmplitudeZS::produce(), IPTCorrector::produce(), DistortedMuonProducer::produce(), pat::PATTauSlimmer::produce(), DAFTrackProducer::produce(), HcalCalibFEDSelector::produce(), FamosProducer::produce(), TrackProducerWithSCAssociation::produce(), cms::SubEventGenJetProducer::produce(), PFClusterTimeSelector::produce(), L1HLTJetsMatching::produce(), L1THLTTauMatching::produce(), PFJetsMatchedToFilteredCaloJetsProducer::produce(), ISRGammaWeightProducer::produce(), GlobalCosmicMuonProducer::produce(), CollectionAdder< C >::produce(), CleanAndMergeProducer::produce(), EgammaHLTHybridClusterProducer::produce(), ElectronSeedTrackRefFix::produce(), BunchSpacingProducer::produce(), CSCSegmentProducer::produce(), HBHEIsolatedNoiseReflagger::produce(), JetTracksAssociatorAtCaloFace::produce(), PFDisplacedTrackerVertexProducer::produce(), PFNuclearProducer::produce(), GenParticlePruner::produce(), CSCTFTrackProducer::produce(), MCTrackMatcher::produce(), L1HLTTauMatching::produce(), HLTJetL1MatchProducer< T >::produce(), UpdatedMuonInnerTrackRef::produce(), ME0SegmentProducer::produce(), FSRWeightProducer::produce(), ISRWeightProducer::produce(), RPCPointProducer::produce(), EcalTPSkimmer::produce(), DTUnpackingModule::produce(), EcalDigiSelector::produce(), AnyJetToCaloJetProducer::produce(), HFRecoEcalCandidateProducer::produce(), ShallowClustersProducer::produce(), PFClusterCollectionMerger::produce(), LightPFTrackProducer::produce(), HLTTauRefCombiner::produce(), HIPixelClusterVtxProducer::produce(), ME0DigiPreRecoProducer::produce(), ParticleBasedIsoProducer::produce(), L2TauPixelTrackMatch::produce(), HLTJetL1TMatchProducer< T >::produce(), IsolatedEcalPixelTrackCandidateProducer::produce(), CalibratedElectronProducerRun2T< T >::produce(), PdfWeightProducer::produce(), TtFullLepKinSolutionProducer::produce(), CSCDCCUnpacker::produce(), pat::helper::AnythingToValueMap< Adaptor, Collection, value_type >::produce(), ESDigiToRaw::produce(), HybridClusterProducer::produce(), RecHitFilter::produce(), EgammaHLTIslandClusterProducer::produce(), FastTrackerRecHitCombiner::produce(), ZdcSimpleReconstructor::produce(), PFConversionProducer::produce(), reco::ParticleFlowForChargedMETProducer::produce(), PFV0Producer::produce(), L3MuonSumCaloPFIsolationProducer::produce(), CaloMuonMerger::produce(), TtFullHadSignalSelMVAComputer::produce(), SimHitTPAssociationProducer::produce(), ScaleCorrMETData::produce(), CollectionFromZLegProducer::produce(), JetTagProducer::produce(), PixelTracksProducer::produce(), CaloTowersCreator::produce(), ElectronIDExternalProducer< algo >::produce(), PileupJPTJetIdProducer::produce(), PUFilter::produce(), CaloTowerCandidateCreator::produce(), TSGFromL2Muon::produce(), TSGFromL1Muon::produce(), HLTHcalTowerNoiseCleanerWithrechit::produce(), TtSemiLepHitFitProducer< LeptonCollection >::produce(), reco::modulesNew::MCTruthCompositeMatcher::produce(), ConeIsolation::produce(), CaloMuonProducer::produce(), IsoTracks::produce(), JetVetoedTracksAssociatorAtVertex::produce(), JetTracksAssociationToTrackRefs::produce(), HLTHcalTowerNoiseCleaner::produce(), pat::PATGenJetSlimmer::produce(), pat::PATMuonSlimmer::produce(), ProbeMulteplicityProducer::produce(), EgammaHLTCaloTowerProducer::produce(), NtpProducer< C >::produce(), EgammaEcalPFClusterIsolationProducer< T1 >::produce(), EgammaHcalPFClusterIsolationProducer< T1 >::produce(), EgammaHLTMulti5x5ClusterProducer::produce(), GEMCSCSegmentProducer::produce(), RecoTauPiZeroUnembedder::produce(), MuonRefProducer::produce(), GEDPhotonCoreProducer::produce(), JetCoreClusterSplitter::produce(), ElectronPATIdMVAProducer::produce(), pat::PATElectronSlimmer::produce(), CastorDigiToRaw::produce(), PreshowerClusterProducer::produce(), PreshowerPhiClusterProducer::produce(), ReducedESRecHitCollectionProducer::produce(), FastTrackerRecHitMaskProducer::produce(), ConstrainedFitCandProducer< Fitter, InputCollection, OutputCollection, Init >::produce(), MVAJetPuIdProducer::produce(), pat::PATJetSlimmer::produce(), EcalRecHitProducer::produce(), CandReducer::produce(), PreshowerClusterShapeProducer::produce(), MuonLinksProducerForHLT::produce(), TtSemiEvtSolutionMaker::produce(), MuonSelectionTypeValueMapProducer::produce(), GEMPadDigiProducer::produce(), PFMultiDepthClusterProducer::produce(), CosmicSeedGenerator::produce(), TtSemiLepSignalSelMVAComputer::produce(), L1TTwinMuxProducer::produce(), GenTrackMatcher::produce(), GEMDigiProducer::produce(), HLTMuonL2SelectorForL3IO::produce(), bestPVselector< T1 >::produce(), ZMuMuTrackUserData::produce(), TtSemiLepJetCombMVAComputer::produce(), TtHadEvtSolutionMaker::produce(), pat::PATPhotonSlimmer::produce(), ColinsSoperVariablesComputer::produce(), CandidateTriggerObjectProducer::produce(), ObjectMultiplicityCounter< T >::produce(), HcalDigiToRaw::produce(), HcalHistogramRawToDigi::produce(), reco::modulesNew::Matcher< C1, C2, S, D >::produce(), DTRecSegment4DProducer::produce(), ElectronIDValueMapProducer::produce(), L2TauPixelIsoTagProducer::produce(), PFDisplacedVertexProducer::produce(), PuppiPhoton::produce(), PFClusterProducer::produce(), ShallowCloneProducer< C >::produce(), CloneProducer< C >::produce(), reco::modules::MatcherBase< C1, C2, M >::produce(), ZMuMuMuonUserData::produce(), TauGenJetProducer::produce(), MuonFromPVSelector::produce(), SiPixelClusterShapeCacheProducer::produce(), TrackInfoProducer::produce(), OtherObjectVariableComputer< T >::produce(), RPCPackingModule::produce(), photonIsolationHIProducer::produce(), cms::MuonMET::produce(), HLTPFJetIDProducer::produce(), RPCDigiProducer::produce(), HGCalRecHitProducer::produce(), TrackFromPVSelector::produce(), pat::PATLostTracks::produce(), pat::RecoMETExtractor::produce(), CastorRawToDigi::produce(), reco::CorrectedJetProducer< T >::produce(), GenParticleProducer::produce(), RPCUnpackingModule::produce(), EgammaHLTPixelMatchVarProducer::produce(), EgammaHLTRecoEcalCandidateProducers::produce(), PFDisplacedVertexCandidateProducer::produce(), TotemRPRecHitProducer::produce(), QjetsAdder::produce(), ParticleTowerProducer::produce(), JVFJetIdProducer::produce(), ShiftedMETcorrInputProducer::produce(), ElectronRecalibSuperClusterAssociator::produce(), MuonLinksProducer::produce(), DeltaBetaWeights::produce(), GlobalTrackQualityProducer::produce(), ZMuMuUserDataOneTrack::produce(), ZMuMuUserData::produce(), NearbyCandCountComputer::produce(), HcalRawToDigi::produce(), BeamSpotOnlineProducer::produce(), CollectionCombiner< Collection >::produce(), pat::GenMETExtractor::produce(), cms::JetVertexAssociation::produce(), EcalDetIdToBeRecoveredProducer::produce(), TotemRPClusterProducer::produce(), pat::PATTrackAndVertexUnpacker::produce(), TopBottomClusterInfoProducer::produce(), HLTDisplacedmumumuVtxProducer::produce(), CSCRecHitDProducer::produce(), MuonMETcorrInputProducer::produce(), EgammaHLTCombinedIsolationProducer::produce(), EgammaHLTRemoveDuplicatedSC::produce(), HLTCaloTowerHtMhtProducer::produce(), citk::PFIsolationSumProducerForPUPPI::produce(), MuonReSeeder::produce(), EgammaHLTPFChargedIsolationProducer::produce(), pat::MatcherUsingTracks::produce(), TriggerObjectFilterByCollection::produce(), TauJetSelectorForHLTTrackSeeding::produce(), ME0MuonTrackCollProducer::produce(), PiZeroDiscriminatorProducer::produce(), SubdetFEDSelector::produce(), pat::PATTriggerObjectStandAloneUnpacker::produce(), PuppiProducer::produce(), VersionedIdProducer< PhysicsObjectPtr, SelectorType >::produce(), ShiftedJetProducerByMatchedObjectT< T >::produce(), EgammaHLTElectronCombinedIsolationProducer::produce(), EgammaHLTPFNeutralIsolationProducer::produce(), SiPixelDigiToRaw::produce(), PhotonCoreProducer::produce(), edm::FwdPtrProducer< T, H >::produce(), EgammaHLTPFPhotonIsolationProducer::produce(), ShiftedParticleMETcorrInputProducer::produce(), PFMET::produce(), EgammaHLTClusterShapeProducer::produce(), SysShiftMETcorrInputProducer::produce(), PileupInformation::produce(), Type1PFMET::produce(), cms::JetCorrectionProducer< T >::produce(), pat::DuplicatedElectronCleaner::produce(), CSCDigiToRawModule::produce(), CSCTFPacker::produce(), ConversionTrackMerger::produce(), HLTDisplacedmumuVtxProducer::produce(), sistrip::DigiToRawModule::produce(), edm::ProductFromFwdPtrProducer< T, H >::produce(), Type0PFMETcorrInputProducer::produce(), SoftPFMuonTagInfoProducer::produce(), InputGenJetsParticleSelector::produce(), pat::PATVertexAssociationProducer::produce(), SiStripRegFEDSelector::produce(), EgammaHLTEcalRecIsolationProducer::produce(), SiPixelRawToDigi::produce(), PFRecoTauProducer::produce(), ElectronConversionRejectionVars::produce(), HLTEcalPFClusterIsolationProducer< T1 >::produce(), MuonShowerInformationProducer::produce(), HcalTBObjectUnpacker::produce(), pat::L1MuonMatcher::produce(), GsfElectronFromPVSelector::produce(), HLTMhtProducer::produce(), HLTHcalPFClusterIsolationProducer< T1 >::produce(), EgammaHLTRegionalPixelSeedGeneratorProducers::produce(), SoftPFElectronTagInfoProducer::produce(), TSGForOI::produce(), PFRecoTauTagInfoProducer::produce(), pat::HLTL1MuonMatcher::produce(), HLTMETCleanerUsingJetID::produce(), HLTTauMCProducer::produce(), TrackListMerger::produce(), TtFullHadHypothesis::produce(), SimpleTrackListMerger::produce(), PFCandMETcorrInputProducer::produce(), ShiftedPFCandidateProducerByMatchedObject::produce(), MultShiftMETcorrInputProducer::produce(), Merger< InputCollection, OutputCollection, P >::produce(), PFTrackProducer::produce(), NoPileUpPFMEtProducer::produce(), HLTHtMhtProducer::produce(), HSCPDeDxInfoProducer::produce(), ZllArbitrator< T1 >::produce(), RecoTauJetRegionProducer::produce(), PixelVertexProducer::produce(), DeDxHitInfoProducer::produce(), pat::PATPackedCandidateProducer::produce(), SiStripElectronProducer::produce(), EgammaHLTElectronDetaDphiProducer::produce(), EgammaHLTHcalIsolationDoubleConeProducers::produce(), EleIsoDetIdCollectionProducer::produce(), TotemRPLocalTrackFitter::produce(), EgammaHLTElectronTrackIsolationProducers::produce(), pat::PATJetUpdater::produce(), TrackAssociatorEDProducer::produce(), PFLinker::produce(), CaloTowerFromL1TCreatorForTauHLT::produce(), ReducedRecHitCollectionProducer::produce(), MVAValueMapProducer< ParticleType >::produce(), HLTCaloJetIDProducer::produce(), ClusterTPAssociationProducer::produce(), EcalIsolatedParticleCandidateProducer::produce(), HLTDisplacedtktkVtxProducer::produce(), TtSemiLepHypothesis::produce(), PFchsMETcorrInputProducer::produce(), CSCTFUnpacker::produce(), HLTmumutktkVtxProducer::produce(), ConvertedPhotonProducer::produce(), HLTCollectionProducer< T >::produce(), WMuNuProducer::produce(), FastTrackerRecHitMatcher::produce(), ZdcHitReconstructor::produce(), citk::PFIsolationSumProducer::produce(), CaloTowerCreatorForTauHLT::produce(), CosmicsMuonIdProducer::produce(), ShiftedPFCandidateProducerForPFMVAMEt::produce(), AlCaEcalHcalReadoutsProducer::produce(), ClusterCompatibilityProducer::produce(), ConversionSeedFilterCharge::produce(), TtEvtBuilder< C >::produce(), CosmicTrackSelector::produce(), HLTTrackClusterRemoverNew::produce(), MixEvtVtxGenerator::produce(), JetSubstructurePacker::produce(), EgammaSCCorrectionMaker::produce(), L1TMuonQualityAdjuster::produce(), EgammaHLTHcalIsolationProducersRegional::produce(), ShiftedParticleProducer::produce(), IsolationProducer< C1, C2, Alg, OutputCollection, Setup >::produce(), GlobalMuonProducer::produce(), PFCTRecHitProducer::produce(), HcalRecHitRecalib::produce(), CSCTriggerPrimitivesProducer::produce(), PartonSelector::produce(), ZToLLEdmNtupleDumper::produce(), Onia2MuMuPAT::produce(), GenFilterEfficiencyProducer::produce(), EgammaHLTBcHcalIsolationProducersRegional::produce(), EgammaHLTR9IDProducer::produce(), AlCaElectronTracksReducer::produce(), HLTL1TMuonSelector::produce(), TtFullLepHypothesis::produce(), pat::PATConversionProducer::produce(), EgammaHLTPhotonTrackIsolationProducersRegional::produce(), PFCand_AssoMap::produce(), pat::PATMETProducer::produce(), BtoCharmDecayVertexMergerT< VTX >::produce(), ConversionTrackCandidateProducer::produce(), pat::PATPackedGenParticleProducer::produce(), PFPileUp::produce(), SiStripFineDelayHit::produce(), SeedClusterRemover::produce(), PATHemisphereProducer::produce(), ECALRegFEDSelector::produce(), HiEgammaSCCorrectionMaker::produce(), VoronoiBackgroundProducer::produce(), EcalTrigPrimProducer::produce(), modules::MuonCleanerBySegmentsT< T >::produce(), HLTRechitInRegionsProducer< T1 >::produce(), AlCaDiJetsProducer::produce(), PrimaryVertexSorter< ParticlesCollection >::produce(), TrackMVAClassifierBase::produce(), cms::MuonMETValueMapProducer::produce(), AlCaGammaJetProducer::produce(), ObjectSelectorProducer< Selector, OutputCollection, PostProcessor, StoreManager, Base, Init >::produce(), EgammaHLTR9Producer::produce(), FakeTrackProducer< T >::produce(), PhotonProducer::produce(), reco::modulesNew::IsolationProducer< C1, C2, Alg, OutputCollection, Setup >::produce(), pat::PATCleaner< PATObjType >::produce(), GamIsoDetIdCollectionProducer::produce(), cms::HitReCalibrator::produce(), HLTJetCollectionsForBoostedLeptonPlusJets< jetType >::produce(), PFProducer::produce(), HLTmumutkVtxProducer::produce(), ScalersRawToDigi::produce(), JetPlusTrackProducer::produce(), HITrackClusterRemover::produce(), pat::PATCompositeCandidateProducer::produce(), RecoTauPiZeroProducer::produce(), HBHENoiseFilterResultProducer::produce(), ConversionSeedFilter::produce(), HLTScoutingCaloProducer::produce(), HLTTrackMETProducer::produce(), HLTJetCollectionsForLeptonPlusJets< jetType >::produce(), CastorJetIDProducer::produce(), GctDigiToRaw::produce(), HiGenCleaner< T2 >::produce(), TrackCandidateProducer::produce(), SiStripElectronAssociator::produce(), EgammaIsoESDetIdCollectionProducer::produce(), HLTJetCollForElePlusJets< T >::produce(), MinMETProducerT< T >::produce(), MuPFIsoEmbedder::produce(), PixelVertexCollectionTrimmer::produce(), TrackMCQuality::produce(), HLTL1MuonSelector::produce(), L1TPhysicalEtAdder::produce(), l1t::L1ComparatorRun2::produce(), HLTJetCollectionsForElePlusJets< T >::produce(), PF_PU_AssoMap::produce(), EgammaHLTEcalIsolationProducersRegional::produce(), TestBXVectorRefProducer::produce(), pat::PATGenericParticleProducer::produce(), FromClusterSummaryMultiplicityProducer::produce(), TrackCandidateTopBottomHitFilter::produce(), OutsideInMuonSeeder::produce(), DeltaRNearestObjectComputer< T >::produce(), MuonTimingProducer::produce(), L1GlobalTriggerRecordProducer::produce(), EventWithHistoryProducerFromL1ABC::produce(), BoostedTauSeedsProducer::produce(), TrackAssociatorByPositionProducer::produce(), GEDPhotonProducer::produce(), HLTScoutingPFProducer::produce(), IsolatedPixelTrackCandidateProducer::produce(), EgammaIsoHcalDetIdCollectionProducer::produce(), pat::PATPFParticleProducer::produce(), NjettinessAdder::produce(), AlCaHcalNoiseProducer::produce(), NoPileUpPFMEtDataProducer::produce(), pat::PATMuonProducer::produce(), cms::MuonTCMETValueMapProducer::produce(), ShiftedPFCandidateProducerForNoPileUpPFMEt::produce(), ShiftedPFCandidateProducerForPFNoPUMEt::produce(), DTDigitizer::produce(), HLTScoutingMuonProducer::produce(), PFSimParticleProducer::produce(), CastorCellProducer::produce(), PhotonIDValueMapProducer::produce(), HLTRechitsToDigis::produce(), pat::TauJetCorrFactorsProducer::produce(), JetIDProducer::produce(), EcalRawToDigi::produce(), CorrectedCaloMETProducer::produce(), HcalHitSelection::produce(), EventShapeVarsProducer::produce(), QuickTrackAssociatorByHitsProducer::produce(), VertexFromTrackProducer::produce(), TrajectorySeedFromMuonProducer::produce(), ElectronSeedProducer::produce(), L1Comparator::produce(), InterestingDetIdFromSuperClusterProducer::produce(), CorrectedPATMETProducer::produce(), IsolatedPixelTrackCandidateL1TProducer::produce(), ExtraFromSeeds::produce(), EgammaHLTNxNClusterProducer::produce(), InterestingDetIdCollectionProducer::produce(), TrackMultiSelector::produce(), L1TMuonLegacyConverter::produce(), pat::PATTauProducer::produce(), TtJetPartonMatch< C >::produce(), HcalHitReconstructor::produce(), HLTScoutingEgammaProducer::produce(), reco::PFMETProducerMVA::produce(), FFTJetVertexAdder::produce(), L1TBMTFConverter::produce(), ReducedEGProducer::produce(), TrackAssociatorByChi2Producer::produce(), ValueMapTraslator::produce(), MuScleFitMuonProducer::produce(), pat::PATJetProducer::produce(), FFTJetPFPileupCleaner::produce(), pat::MatcherByPulls< T >::produce(), RecHitCorrector::produce(), RecoTauProducer::produce(), MuonSegmentProducer::produce(), DeDxEstimatorProducer::produce(), InterestingTrackEcalDetIdProducer::produce(), CaloTowersMerger::produce(), PF_PU_FirstVertexTracks::produce(), CentralityBinProducer::produce(), GenHIEventProducer::produce(), FFTJetPileupEstimator::produce(), SoftKillerProducer::produce(), L1TMuonEndCapTrackProducer::produce(), EcalDigiToRaw::produce(), ConversionTrackProducer::produce(), PFTauSecondaryVertexProducer::produce(), AlCaECALRecHitReducer::produce(), HiSpikeCleaner::produce(), pat::PATTriggerMatchEmbedder< PATObjectType >::produce(), CastorClusterProducer::produce(), L1TMuonCaloSumProducer::produce(), TrackFromSeedProducer::produce(), ConditionDumperInEdm::produce(), PileupJetIdProducer::produce(), L1TCaloUpgradeToGCTConverter::produce(), PatJPsiProducer::produce(), CaloRecHitsBeamHaloCleaned::produce(), L2MuonSeedGeneratorFromL1T::produce(), CastorTowerProducer::produce(), AlCaHBHEMuonProducer::produce(), NuclearSeedsEDProducer::produce(), MultiplicityProducer< T >::produce(), l1t::L1TCaloRCTToUpgradeConverter::produce(), TrackAssociatorByHitsProducer::produce(), HiL1Subtractor::produce(), TauSpinnerCMS::produce(), NuclearInteractionEDProducer::produce(), TcdsRawToDigi::produce(), SiTrackerGaussianSmearingRecHitConverter::produce(), HLTPrescaleRecorder::produce(), L1TExtCondLegacyToStage2::produce(), MixBoostEvtVtxGenerator::produce(), L1GTEvmDigiToRaw::produce(), PrimaryVertexProducer::produce(), ObjectViewMatcher< T1, T2 >::produce(), L2MuonSeedGenerator::produce(), L1TMicroGMTInputProducerFromGen::produce(), PFRecoTauChargedHadronProducer::produce(), PFCand_NoPU_WithAM::produce(), pat::PATPhotonProducer::produce(), BetaBoostEvtVtxGenerator::produce(), GenJetBCEnergyRatio::produce(), JetDeltaRTagInfoValueMapProducer< T, I >::produce(), pat::PATTriggerEventProducer::produce(), SiPixelClusterProducer::produce(), CorrectedECALPFClusterProducer::produce(), JetPlusTrackProducerAA::produce(), pat::PATElectronProducer::produce(), reco::CentralityProducer::produce(), ObjectViewCleaner< T >::produce(), TrackAlgoCompareUtil::produce(), SeedToTrackProducer::produce(), reco::modules::HICaloCompatibleTrackSelector::produce(), HighPtTrackEcalDetIdProducer::produce(), reco::modules::TrackFullCloneSelectorBase< Selector >::produce(), L1GTDigiToRaw::produce(), FastPrimaryVertexWithWeightsProducer::produce(), PFTauTransverseImpactParameters::produce(), BoostedJetMerger::produce(), APVCyclePhaseProducerFromL1ABC::produce(), RecoTauCleanerImpl< Prod >::produce(), TrackExtrapolator::produce(), PixelJetPuId::produce(), PFEGammaProducer::produce(), CorrectedPFMETProducer::produce(), L1TStage2Layer2Producer::produce(), APVCyclePhaseProducerFromL1TS::produce(), FlavorHistoryProducer::produce(), reco::BeamHaloSummaryProducer::produce(), L1TMuonProducer::produce(), sistrip::FEDEmulatorModule::produce(), GenHFHadronMatcher::produce(), l1t::GenToInputProducer::produce(), l1t::BXVectorInputProducer::produce(), ShiftedParticleProducerT< T >::produce(), L1TCaloLayer1::produce(), ReduceHcalRecHitCollectionProducer::produce(), pat::PATTriggerProducer::produce(), HiEvtPlaneFlatProducer::produce(), ShallowGainCalibration::produce(), TrackClusterSplitter::produce(), PhotonRegressionValueMapProducer::produce(), PFElecTkProducer::produce(), CATopJetTagger::produce(), pat::JetCorrFactorsProducer::produce(), EgammaHLTGsfTrackVarProducer::produce(), reco::PhysObjectMatcher< C1, C2, S, D, Q >::produce(), ElectronRegressionValueMapProducer::produce(), ME0MuonConverter::produce(), pat::helper::ManyThingsToValueMaps< Adaptor, Collection, value_type >::produce(), L1TStage2Layer1Producer::produce(), JetDeltaRValueMapProducer< T, C >::produce(), PFTauPrimaryVertexProducer::produce(), ClusterSummaryProducer::produce(), ProduceIsolationMap::produce(), MuonMCClassifier::produce(), ConversionProducer::produce(), cms::CosmicTrackFinder::produce(), cms::SiPixelRecHitConverter::produce(), L1TStage1Layer2Producer::produce(), reco::modules::TrackerTrackHitFilter::produce(), MuonSimHitProducer::produce(), FastPrimaryVertexProducer::produce(), reco::modules::CosmicTrackSplitter::produce(), GoodSeedProducer::produce(), HLTJetsCleanedFromLeadingLeptons< JetType >::produce(), ME0SegmentMatcher::produce(), GenTtbarCategorizer::produce(), HadronAndPartonSelector::produce(), TrajectorySeedProducer::produce(), BoostedTopProducer::produce(), CandidateProducer< TColl, CColl, Selector, Conv, Creator, Init >::produce(), VirtualJetProducer::produce(), SelectedElectronFEDListProducer< TEle, TCand >::produce(), ShiftedJetProducerT< T, Textractor >::produce(), reco::HcalHaloDataProducer::produce(), AlCaIsoTracksProducer::produce(), reco::modules::JetFlavourIdentifier::produce(), CorrectedMETProducerT< T >::produce(), JetPartonMatcher::produce(), reco::EcalHaloDataProducer::produce(), CaloJetMETcorrInputProducerT< T, Textractor >::produce(), Type2CorrectionProducer::produce(), ChainedJetCorrectorProducer::produce(), JetCleanerForType1METT< T, Textractor >::produce(), reco::modules::NamedCandCombiner< Selector, PairSelector, Cloner, Setup, Init >::produce(), reco::CSCHaloDataProducer::produce(), IPProducer< Container, Base, Helper >::produce(), reco::modules::CandCombiner< Selector, PairSelector, Cloner, OutputCollection, Setup, Init >::produce(), JetFlavourClustering::produce(), PFJetMETcorrInputProducerT< T, Textractor >::produce(), TopProjector< Top, Bottom, Matcher >::produce(), AlCaHOCalibProducer::produce(), EvtPlaneProducer::produce(), reco::GlobalHaloDataProducer::produce(), SiStripClusterizerFromRaw::produce(), cms::CkfTrackCandidateMakerBase::produceBase(), SiStripFineDelayHit::produceNoTracking(), FastjetJetProducer::produceTrackJets(), KfTrackProducerBase::putInEvt(), GsfTrackProducerBase::putInEvt(), TrackProducerWithSCAssociation::putInEvt(), MuonCosmicCompatibilityFiller::pvMatches(), pat::PATMETSlimmer::OneMETShift::readAndSet(), ElectronHcalHelper::readEvent(), BeamFitter::readEvent(), PVFitter::readEvent(), pat::helper::BasicOverlapTest::readInput(), pat::helper::OverlapBySuperClusterSeed::readInput(), TauSpinnerCMS::readParticlesfromReco(), L1MuBMSectorReceiver::receiveBBMXData(), l1t::GlobalBoard::receiveCaloObjectData(), L1MuDTSectorReceiver::receiveCSCData(), L1MuDTEtaProcessor::receiveData(), L1MuBMEtaProcessor::receiveData(), L1MuDTSectorReceiver::receiveDTBXData(), l1t::GlobalBoard::receiveExternalData(), l1t::GlobalBoard::receiveMuonObjectData(), HcalDigiTester::reco(), HcalDigisValidation::reco(), MuonTrackingRegionBuilder::region(), GlobalTrackingRegionProducerFromBeamSpot::regions(), HIMuonTrackingRegionProducer::regions(), IsolationRegionAroundL3Muon::regions(), GlobalTrackingRegionWithVerticesProducer::regions(), MuonTrackingRegionBuilder::regions(), L3MumuTrackingRegion::regions(), TrackingRegionsFromBeamSpotAndL2Tau::regions(), TauRegionalPixelSeedGenerator::regions(), HITRegionalPixelSeedGenerator::regions(), HITrackingRegionForPrimaryVtxProducer::regions(), CandidateSeededTrackingRegionsProducer::regions(), PointSeededTrackingRegionsProducer::regions(), RunManagerMTWorker::resetGenParticleId(), CutsIsolatorWithCorrection::result(), l1t::L1TGlobalUtil::retrieveL1Event(), L1RetrieveL1Extra::retrieveL1ExtraObjects(), CutBasedElectronID::robustSelection(), GenericTripletGenerator::run(), BeamHaloPairGenerator::run(), GenericPairGenerator::run(), tnp::TagProbePairMaker::run(), EcalRecHitWorkerRecover::run(), AnalyticalTrackSelector::run(), EgammaHLTPixelMatchElectronAlgo::run(), PixelUnpackingRegions::run(), MultiTrackSelector::run(), ElectronSeedGenerator::run(), HIMultiTrackSelector::run(), L1MuDTTrackFinder::run(), L1MuBMTrackFinder::run(), SiStripElectronSeedGenerator::run(), pat::helper::AnyNumberAssociationAdaptor::run_(), EcalDQMonitorTask::runOnCollection(), SeedFilter::seeds(), HLTLevel1GTSeed::seedsL1Extra(), HLTL1TSeed::seedsL1TriggerObjectMaps(), HLTLevel1GTSeed::seedsL1TriggerObjectMaps(), GenJetClosestMatchSelectorDefinition::select(), pf2pat::IsolatedPFCandidateSelectorDefinition::select(), pf2pat::IPCutPFCandidateSelectorDefinition::select(), StringCutEventSelector< Object, any >::select(), CaloTauSelectorDefinition::select(), AssociatedVariableCollectionSelector< InputCollection, VarCollection, Selector, OutputCollection, StoreContainer, RefAdder >::select(), HIProtoTrackSelector::select(), PFTauSelectorDefinition::select(), pf2pat::ElectronIDPFCandidateSelectorDefinition::select(), StringCutsEventSelector< Object, existenceMatter >::select(), SelectionStepHLT< Object >::select(), SelectionStep< Object >::select(), DualByL2TSG::selectTSG(), SelectionStepHLT< Object >::selectVertex(), SelectionStep< Object >::selectVertex(), L1Analysis::L1AnalysisEvent::Set(), EcalUncalibRecHitWorkerMultiFit::set(), ClusterShapeTrajectoryFilter::setEvent(), reco::isodeposit::OtherCandidatesDeltaRVeto::setEvent(), BaselinePFSCRegression::setEvent(), EGExtraInfoModifierFromFloatValueMaps::setEvent(), EGExtraInfoModifierFromIntValueMaps::setEvent(), SCEnergyCorrectorSemiParm::setEvent(), TSGFromPropagation::setEvent(), reco::isodeposit::OtherCandVeto::setEvent(), EGPfIsolationModifierFromValueMaps::setEvent(), EGExtraInfoModifierFromDB::setEvent(), reco::tau::RecoTauVertexAssociator::setEvent(), FastTSGFromPropagation::setEvent(), EGFull5x5ShowerShapeModifierFromValueMaps::setEvent(), ConversionSeedFinder::setEvent(), TrackAnalyzer::setLumi(), TrackingMonitor::setNclus(), TrackAnalyzer::setNumberOfGoodVertices(), VoronoiSubtractor::setupGeometryMap(), ParametrizedSubtractor::setupGeometryMap(), SimHitMatcher::SimHitMatcher(), SiStripZeroSuppression::StandardZeroSuppression(), IsoTrig::studyTiming(), ClusterChecker::tooManyClusters(), TrackerHitAssociator::TrackerHitAssociator(), FastTSGFromIOHit::trackerSeeds(), TrackingParticleNumberOfLayers::TrackingParticleNumberOfLayers(), TrackCollectionTokens::tracks(), SiStripMonitorTrack::trackStudy(), TrackCollectionTokens::trajectories(), DTLocalTriggerTask::triggerSource(), SimpleCosmicBONSeeder::triplets(), HIProtoTrackFilter::update(), HIPixelTrackFilter::update(), ClusterShapeTrackFilter::update(), MeasurementTrackerEventProducer::updatePixels(), WeightManager::weight(), and ECALRecHitAnalyzer::WriteECALRecHits().
bool Event::getByToken | ( | EDGetTokenT< PROD > | token, |
Handle< PROD > & | result | ||
) | const |
Definition at line 475 of file Event.h.
References addToGotBranchIDs(), edm::HandleBase::clear(), edm::convert_handle(), edm::HandleBase::failedToGet(), edm::PrincipalGetAdapter::getByToken_(), moduleCallingContext_, eostools::move(), PROD, edm::PRODUCT_TYPE, edm::HandleBase::provenance(), and provRecorder_.
bool Event::getByToken | ( | EDGetToken | token, |
Handle< View< ELEMENT >> & | result | ||
) | const |
Definition at line 525 of file Event.h.
References edm::ELEMENT_TYPE, edm::BasicHandle::failedToGet(), fillView_(), edm::PrincipalGetAdapter::getByToken_(), h, moduleCallingContext_, eostools::move(), provRecorder_, mps_fire::result, edm::HandleBase::swap(), and edm::BasicHandle::whyFailedFactory().
bool Event::getByToken | ( | EDGetTokenT< View< ELEMENT >> | token, |
Handle< View< ELEMENT >> & | result | ||
) | const |
Definition at line 539 of file Event.h.
References edm::ELEMENT_TYPE, edm::BasicHandle::failedToGet(), fillView_(), edm::PrincipalGetAdapter::getByToken_(), h, moduleCallingContext_, eostools::move(), provRecorder_, mps_fire::result, edm::HandleBase::swap(), unpackBuffers-CaloStage2::token, and edm::BasicHandle::whyFailedFactory().
|
privatevirtual |
Implements edm::EventBase.
Definition at line 206 of file Event.cc.
References addToGotBranchIDs(), getByProductID_(), h, edm::BasicHandle::isValid(), and edm::BasicHandle::provenance().
|
inline |
Definition at line 85 of file Event.h.
References luminosityBlock_.
Referenced by EventHeader::analyze(), StudyHLT::analyze(), PixelLumiDQM::analyze(), Vx3DHLTAnalyzer::analyze(), TrackCount::analyze(), IsoTrig::analyze(), IsolatedTracksCone::analyze(), VertexHistogramMaker::fill(), DigiLumiCorrHistogramMaker::fill(), HLTPrescaler::filter(), GetLumi::getRawValue(), and getRun().
Definition at line 452 of file Event.h.
References addToGotBranchIDs(), edm::PrincipalGetAdapter::getManyByType(), moduleCallingContext_, provRecorder_, and mps_update::results.
Referenced by HtrXmlPattern::analyze(), myJetAna::analyze(), EnergyScaleAnalyzer::analyze(), SelectReplacementCandidates::determineMuonsToUse(), GlobalHitsAnalyzer::fillG4MC(), GlobalHitsProdHist::fillG4MC(), GlobalHitsProducer::fillG4MC(), GlobalRecHitsAnalyzer::fillHCal(), GlobalRecHitsProducer::fillHCal(), myFilter::filter(), cms::MTCCHLTrigger::filter(), Herwig6Filter::filter(), egHLT::debug::listAllProducts(), HSCPValidator::makeSimDigiPlotsRPC(), ESRecHitsMerger::produce(), EcalRecHitsMerger::produce(), EcalListOfFEDSProducer::produce(), ESListOfFEDSProducer::produce(), SimHitShifter::produce(), and SelectReplacementCandidates::ProductNotFound().
bool Event::getProcessParameterSet | ( | std::string const & | processName, |
ParameterSet & | ps | ||
) | const |
Definition at line 95 of file Event.cc.
References assert(), mps_alisetup::config, edm::ParameterSet::empty(), edm::ProcessHistory::getConfigurationForProcess(), edm::pset::Registry::getMapped(), edm::pset::Registry::instance(), edm::ProcessConfiguration::parameterSetID(), and processHistory().
Provenance Event::getProvenance | ( | BranchID const & | theID | ) | const |
Definition at line 80 of file Event.cc.
References edm::Principal::getProvenance(), moduleCallingContext_, edm::PrincipalGetAdapter::principal(), and provRecorder_.
Referenced by HLTInfo::analyze(), TriggerSummaryProducerAOD::fillFilterObjectMembers(), EcalSelectiveReadoutProducer::getBinOfMax(), HLTDoubletDZ< T1, T2 >::getCollections(), HLTMuonL3PreFilter::hltFilter(), HLTDoublet< T1, T2 >::hltFilter(), PFCandidateMixer::mix(), OniaVtxReProducer::OniaVtxReProducer(), GlobalTrackQualityProducer::produce(), TrackListMerger::produce(), SimpleTrackListMerger::produce(), and HadronAndPartonSelector::produce().
Provenance Event::getProvenance | ( | ProductID const & | theID | ) | const |
Definition at line 85 of file Event.cc.
References eventPrincipal(), edm::EventPrincipal::getProvenance(), and moduleCallingContext_.
Returns a RefProd to a product before that product has been placed into the Event. The RefProd (and any Ref's made from it) will no work properly until after the Event has been committed (which happens after leaving the EDProducer::produce method)
Definition at line 141 of file Event.h.
References AlCaHLTBitMon_QueryRunRegistry::string.
Referenced by HLTRFilter::addObjects(), helper::CandDecayStoreManager::cloneAndStore(), pat::PATJetSelector::filter(), QualityFilter::produce(), GenParticleDecaySelector::produce(), TopInitSubset::produce(), AssociationVectorSelector< KeyRefProd, CVal, KeySelector, ValSelector >::produce(), MuonTrackProducer::produce(), GenParticlePruner::produce(), PFDisplacedTrackerVertexProducer::produce(), PFNuclearProducer::produce(), PFConversionProducer::produce(), PFV0Producer::produce(), PFRecHitProducer::produce(), RecoTauPiZeroUnembedder::produce(), ElectronRecalibSuperClusterAssociator::produce(), GenParticleProducer::produce(), ME0MuonTrackCollProducer::produce(), SimpleTrackListMerger::produce(), TrackListMerger::produce(), pat::PATJetUpdater::produce(), FastTrackerRecHitMatcher::produce(), CosmicTrackSelector::produce(), PFCTRecHitProducer::produce(), FakeTrackProducer< T >::produce(), BoostedTauSeedsProducer::produce(), TrackMultiSelector::produce(), ExtraFromSeeds::produce(), pat::PATJetProducer::produce(), GsfTrackMixer::produce(), MuonErrorMatrixAdjuster::produce(), PFTauSecondaryVertexProducer::produce(), TrackFromSeedProducer::produce(), SiTrackerGaussianSmearingRecHitConverter::produce(), reco::modules::HICaloCompatibleTrackSelector::produce(), SeedToTrackProducer::produce(), BoostedJetMerger::produce(), PFTauTransverseImpactParameters::produce(), PFEGammaProducer::produce(), PFTauPrimaryVertexProducer::produce(), NuclearTrackCorrector::produce(), PFTau3ProngReco::produce(), IPProducer< Container, Base, Helper >::produce(), TrackCollectionCloner::Producer::Producer(), TrackMixerBase::produceTracks(), MuonTrackCleanerBase::produceTracks(), KfTrackProducerBase::putInEvt(), GsfTrackProducerBase::putInEvt(), TrackProducerWithSCAssociation::putInEvt(), and AnalyticalTrackSelector::run().
RefProd< PROD > Event::getRefBeforePut | ( | std::string const & | productInstanceName | ) |
Definition at line 407 of file Event.h.
References edm::PrincipalGetAdapter::getBranchDescription(), makeProductID(), AlCaHLTBitMon_ParallelJobs::p, PROD, edm::PrincipalGetAdapter::prodGetter(), and provRecorder_.
Run const & Event::getRun | ( | ) | const |
Definition at line 65 of file Event.cc.
References getLuminosityBlock(), and edm::LuminosityBlock::getRun().
Referenced by CosmicRateAnalyzer::analyze(), L1GtAnalyzer::analyzeL1GtTriggerMenuLite(), MuScleFit::duringLoop(), AdHocNTupler::fill(), L1GtBeamModeFilter::filter(), L1GtUtils::getL1GtRunCache(), and HLTPrescaleProvider::prescaleValuesInDetail().
|
inline |
Definition at line 227 of file Event.h.
References edm::PrincipalGetAdapter::labelsForToken(), and provRecorder_.
Referenced by TrackerHitAssociator::makeMaps().
|
private |
Definition at line 60 of file Event.cc.
References edm::EventPrincipal::branchIDToProductID(), eventPrincipal(), and edm::BranchDescription::originalBranchID().
Referenced by getRefBeforePut(), and put().
|
inline |
Definition at line 225 of file Event.h.
References moduleCallingContext_.
Referenced by edm::SecSourceAnalyzer::analyze(), edm::DataMixingModule::doPileUp(), edm::MixingModule::doPileUp(), and HLTPrescaler::filter().
|
virtual |
Implements edm::EventBase.
Definition at line 187 of file Event.cc.
References edm::PrincipalGetAdapter::processHistory(), and provRecorder_.
Referenced by getProcessParameterSet(), EcalDeadCellTriggerPrimitiveFilter::loadEventInfoForFilter(), and FWPathsPopup::postEvent().
ProcessHistoryID const & Event::processHistoryID | ( | ) | const |
Definition at line 75 of file Event.cc.
References eventPrincipal(), and edm::Principal::processHistoryID().
EDProductGetter const & Event::productGetter | ( | ) | const |
Definition at line 55 of file Event.cc.
References edm::PrincipalGetAdapter::principal(), and provRecorder_.
Referenced by MuonAssociatorByHits::associateRecoToSim(), MuonAssociatorByHits::associateSimToReco(), fillView_(), VertexAssociatorByPositionAndTracksProducer::produce(), VertexAssociatorByTracksProducer::produce(), CosmicTrackSelector::produce(), PFCand_AssoMap::produce(), BoostedTauSeedsProducer::produce(), QuickTrackAssociatorByHitsProducer::produce(), and TrackAssociatorByHitsProducer::produce().
|
inline |
Put a new product.
Definition at line 121 of file Event.h.
References AlCaHLTBitMon_QueryRunRegistry::string.
Referenced by HLTRFilter::addObjects(), edm::HiMixingWorker< T >::addSignals(), FFTJetCorrectionProducer::applyCorrections(), FFTJetPatRecoProducer::buildDenseProduct(), FFTJetPatRecoProducer::buildSparseProduct(), MCParticleReplacer::call_put(), Multi5x5ClusterProducer::clusterizeECALPart(), EgammaHLTMulti5x5ClusterProducer::clusterizeECALPart(), CosmicClusterProducer::clusterizeECALPart(), IslandClusterProducer::clusterizeECALPart(), EgammaHLTIslandClusterProducer::clusterizeECALPart(), SiStripZeroSuppression::CollectionMergedZeroSuppression(), sistrip::SpyEventMatcherModule::copyData(), HLTTauRefProducer::doElectrons(), HLTTauRefProducer::doJets(), HLTTauRefProducer::doMET(), HLTTauRefProducer::doMuons(), HLTTauRefProducer::doPFTaus(), HLTTauRefProducer::doPhotons(), edm::MixingModule::doPileUp(), HLTTauRefProducer::doTowers(), EDMNeutronWriter::endEvent(), PFRecoTauDiscriminationAgainstElectronMVA6::endEvent(), PFRecoTauDiscriminationAgainstElectronMVA5::endEvent(), PFRecoTauDiscriminationByIsolationMVA2::endEvent(), PFRecoTauDiscriminationByMVAIsolationRun2::endEvent(), VariableNTupler::fill(), StringBasedNTupler::fill(), CSCTightHalo2015Filter::filter(), CSCTightHaloFilter::filter(), CSCTightHaloTrkMuUnvetoFilter::filter(), GlobalSuperTightHalo2016Filter::filter(), GlobalTightHalo2016Filter::filter(), HcalStripHaloFilter::filter(), EENoiseFilter::filter(), cms::MTCCHLTrigger::filter(), JetIDFailureFilter::filter(), TrackingFailureFilter::filter(), cms::TrackMTCCFilter::filter(), HSCParticleSelector::filter(), HLTHcalMETNoiseCleaner::filter(), cms::ClusterMTCCFilter::filter(), cms::TECClusterFilter::filter(), CandViewRefRandomSelector::filter(), MCPdgIndexFilter::filter(), Tau3MuSkim::filter(), PhotonIsoProducer::filter(), ElectronIdMVAProducer::filter(), MultiEventFilter::filter(), GreedyMuonPFCandidateFilter::filter(), ChargedHadronTrackResolutionFilter::filter(), InconsistentMuonPFCandidateFilter::filter(), MuonBadTrackFilter::filter(), pat::PATSingleVertexSelector::filter(), GenMuonRadiationFilter::filter(), ElectronRegressionEnergyProducer::filter(), MuonRadiationFilter::filter(), HLTRHemisphere::filter(), PFTauViewRefSelector::filter(), UniqueObjectSelector< T >::filter(), EcalLaserCorrFilter::filter(), LogErrorEventFilter::filter(), RecoTauPileUpVertexSelector::filter(), pat::PATJetSelector::filter(), MCZll::filter(), EEBadScFilter::filter(), BVertexFilterT< VTX >::filter(), edm::FwdPtrCollectionFilter< T, S, H >::filter(), ConfigurableAnalysis::filter(), JetConstituentSelector< T, C >::filter(), MCVerticesWeight::filter(), JetVertexChecker::filter(), RecoTauDiscriminatorRefSelectorImpl< T >::filter(), edm::GeneratorFilter< HAD, DEC >::filter(), HcalLaserEventFilter::filter(), ByMultiplicityEventFilter< T >::filter(), HSCParticleProducer::filter(), ElectronIdFilter::filter(), aod2patFilterZee::filter(), reco::tau::AssociationMatchRefSelector< InputType, MatchedType, OutputType, ClonePolicy >::filter(), EcalDeadCellBoundaryEnergyFilter::filter(), ElectronIdMVABased::filter(), edm::HadronizerFilter< HAD, DEC >::filter(), HLTEcalResonanceFilter::filter(), HLTRegionalEcalResonanceFilter::filter(), EcalDeadCellTriggerPrimitiveFilter::filter(), FlavorHistoryFilter::filter(), EcalDeadCellDeltaRFilter::filter(), ZeeCandidateFilter::filter(), CastorDigiProducer::finalizeEvent(), HcalTBDigiProducer::finalizeEvent(), RecoTrackAccumulator::finalizeEvent(), cms::PileupVertexAccumulator::finalizeEvent(), SiStripDigitizer::finalizeEvent(), HcalDigitizer::finalizeEvent(), HGCDigitizer::finalizeEvent(), cms::SiPixelDigitizer::finalizeEvent(), HLTDeDxFilter::hltFilter(), HLTMuonPFIsoFilter::hltFilter(), HLTMuonIsoFilter::hltFilter(), HLTHcalPhiSymFilter::hltFilter(), HLTmmkkFilter::hltFilter(), HLTmmkFilter::hltFilter(), ShallowDigisProducer::insert(), gen::Pythia6Gun::loadEvent(), EgammaHLTNxNClusterProducer::makeNxNClusters(), SiStripZeroSuppression::MergeCollectionsZeroSuppression(), PFCandidateMixer::mix(), HcalSimpleReconstructor::process(), MultiTrackSelector::processMVA(), HIMultiTrackSelector::processMVA(), HcalSimpleReconstructor::processUpgrade(), DimuonMCMatcher::produce(), WeakEffectsWeightProducer::produce(), TtGenEventReco::produce(), ShallowEventDataProducer::produce(), MaskedMeasurementTrackerEventProducer::produce(), StGenEventReco::produce(), SiStripRecHitConverter::produce(), PixelVertexProducerMedian::produce(), PatElectronEAIsoCorrectionProducer::produce(), HcalPatternSource::produce(), DoubleProducer::produce(), edm::FlatRandomPtThetaGunProducer::produce(), edm::FlatRandomEThetaGunProducer::produce(), FixedGridRhoProducer::produce(), HcalLaserEventFiltProducer2012::produce(), SeedGeneratorFromProtoTracksEDProducer::produce(), VZeroProducer::produce(), edm::FileRandomKEThetaGunProducer::produce(), HIBestVertexProducer::produce(), HIPixelMedianVtxProducer::produce(), ShallowTracksProducer::produce(), InterestingEcalDetIdProducer::produce(), HepMCCopy::produce(), QualityFilter::produce(), HcalTTPTriggerRecord::produce(), HFEMClusterProducer::produce(), TrackingParticleConversionSelector::produce(), BasicToPFJet::produce(), CastorSimpleReconstructor::produce(), PixelVertexProducerClusters::produce(), JetChargeProducer::produce(), RazorVarProducer::produce(), SeedingLayersEDProducer::produce(), edm::EventAuxiliaryHistoryProducer::produce(), CastorTTRecord::produce(), HcalTTPDigiProducer::produce(), ElectronSqPtTkIsolationProducer::produce(), TtSemiLepJetCombMaxSumPtWMass::produce(), MuonSelectorVertex::produce(), reco::modules::CaloRecHitCandidateProducer< HitCollection >::produce(), ECFAdder::produce(), FixedGridRhoProducerFastjet::produce(), HcalLaserReco::produce(), HGCalUncalibRecHitProducer::produce(), TrackListCombiner::produce(), GenParticleDecaySelector::produce(), ConversionTrackRefFix::produce(), MeasurementTrackerEventProducer::produce(), AlphaTVarProducer::produce(), SeedCombiner::produce(), MuonWithPFIsoProducerCopy::produce(), TopInitSubset::produce(), TtSemiLepJetCombGeom::produce(), TtSemiLepJetCombWMassMaxSumPt::produce(), DistortedMETProducer::produce(), EgammaHLTTimeCleanedRechitProducer::produce(), ShallowRechitClustersProducer::produce(), ElectronSeedMerger::produce(), PhotonConversionTrajectorySeedProducerFromQuadruplets::produce(), SeedGeneratorFromRegionHitsEDProducer::produce(), HcalTrigPrimDigiProducer::produce(), TrackingParticleNumberOfLayersProducer::produce(), MassKinFitterCandProducer::produce(), EventVtxInfoNtupleDumper::produce(), DTDigiToRawModule::produce(), edm::FlatRandomOneOverPtGunProducer::produce(), CSCTFCandidateProducer::produce(), MCTruthCompositeMatcher< C1, C2 >::produce(), ParticleDecayProducer::produce(), EcalTBHodoscopeRecInfoProducer::produce(), EcalTBH2TDCRecInfoProducer::produce(), EcalTBTDCRecInfoProducer::produce(), PhotonConversionTrajectorySeedProducerFromSingleLeg::produce(), GeneratorSmearedProducer::produce(), CSCDigiProducer::produce(), StEvtSolutionMaker::produce(), TtSemiLepKinFitProducer< LeptonCollection >::produce(), UnifiedSCCollectionProducer::produce(), TtDilepEvtSolutionMaker::produce(), edm::FlatRandomEGunProducer::produce(), edm::FlatRandomPtGunProducer::produce(), ShallowTrackClustersProducer::produce(), ShallowSimhitClustersProducer::produce(), CosmicMuonLinksProducer::produce(), PFConcretePFCandidateProducer::produce(), DQMTauProducer::produce(), PFJetToCaloProducer::produce(), PFTauToJetProducer::produce(), CandPtrProjector::produce(), CRackSeedGenerator::produce(), pat::PATVertexSlimmer::produce(), CalibratedPhotonProducerRun2T< T >::produce(), TtSemiLepJetCombWMassDeltaTopMass::produce(), SiStripElectronSeedProducer::produce(), DistortedMuonProducerFromDB::produce(), MuonWithPFIsoProducer::produce(), PhotonIDProducer::produce(), AssociationMapOneToOne2Association< CKey, CVal >::produce(), ESRawToDigi::produce(), AssociationVectorSelector< KeyRefProd, CVal, KeySelector, ValSelector >::produce(), ESRecHitProducer::produce(), EcalUncalibRecHitProducer::produce(), CandOneToOneDeltaRMatcher::produce(), DiJetVarProducer::produce(), pat::PATSecondaryVertexSlimmer::produce(), EmptySimHits::produce(), MuonTrackProducer::produce(), PFMuonCaloCleaner::produce(), UncleanSCRecoveryProducer::produce(), DistortedMuonProducer::produce(), DistortedPFCandProducer::produce(), IPTCorrector::produce(), edm::ExpoRandomPtGunProducer::produce(), edm::MultiParticleInConeGunProducer::produce(), JetExtender::produce(), JetTracksAssociatorAtVertex::produce(), JetTracksAssociatorExplicit::produce(), EcalRecalibRecHitProducer::produce(), AssociationVector2ValueMap< KeyRefProd, CVal >::produce(), QuarkoniaTrackSelector::produce(), RawDataCollectorByLabel::produce(), L2TauJetsMerger::produce(), CandViewRefMerger::produce(), CandOneToManyDeltaRMatcher::produce(), CastorFastTowerProducer::produce(), pat::PATMETSlimmer::produce(), HcalRealisticZS::produce(), HcalSimpleAmplitudeZS::produce(), VertexAssociatorByTracksProducer::produce(), VertexAssociatorByPositionAndTracksProducer::produce(), PFJetsMatchedToFilteredCaloJetsProducer::produce(), EgammaElectronTkIsolationProducer::produce(), EgammaPhotonTkIsolationProducer::produce(), EgammaPhotonTkNumIsolationProducer::produce(), TrackProducerWithSCAssociation::produce(), edm::ExpoRandomPGunProducer::produce(), cms::SubEventGenJetProducer::produce(), HcalCalibFEDSelector::produce(), PFClusterTimeSelector::produce(), L1HLTJetsMatching::produce(), L1THLTTauMatching::produce(), FamosProducer::produce(), RecoTauEventFlagProducer::produce(), CastorFastClusterProducer::produce(), pat::PATTauSlimmer::produce(), HectorProducer::produce(), EcalRecHitsMerger::produce(), EgammaHLTHybridClusterProducer::produce(), HLTJetL1MatchProducer< T >::produce(), ESRecHitsMerger::produce(), ISRGammaWeightProducer::produce(), JetTracksAssociatorAtCaloFace::produce(), HBHEIsolatedNoiseReflagger::produce(), CSCTFTrackProducer::produce(), CSCSegmentProducer::produce(), ME0SegmentProducer::produce(), CollectionAdder< C >::produce(), BunchSpacingProducer::produce(), PFDisplacedTrackerVertexProducer::produce(), PFNuclearProducer::produce(), L1HLTTauMatching::produce(), GenParticlePruner::produce(), EcalTBWeightUncalibRecHitProducer::produce(), ElectronSeedTrackRefFix::produce(), MCTrackMatcher::produce(), UpdatedMuonInnerTrackRef::produce(), CleanAndMergeProducer::produce(), HFRecoEcalCandidateProducer::produce(), HLTHFRecoEcalCandidateProducer::produce(), AnyJetToCaloJetProducer::produce(), FSRWeightProducer::produce(), ISRWeightProducer::produce(), HLTJetL1TMatchProducer< T >::produce(), ParticleBasedIsoProducer::produce(), HLTTauRefCombiner::produce(), HIPixelClusterVtxProducer::produce(), ShallowClustersProducer::produce(), DTUnpackingModule::produce(), EcalTPSkimmer::produce(), RPCPointProducer::produce(), PFClusterCollectionMerger::produce(), LightPFTrackProducer::produce(), L2TauPixelTrackMatch::produce(), IsolatedEcalPixelTrackCandidateProducer::produce(), OscarProducer::produce(), ME0DigiPreRecoProducer::produce(), CalibratedElectronProducerRun2T< T >::produce(), EcalDigiSelector::produce(), HybridClusterProducer::produce(), TtFullHadSignalSelMVAComputer::produce(), RecHitFilter::produce(), TtFullLepKinSolutionProducer::produce(), CollectionFromZLegProducer::produce(), PdfWeightProducer::produce(), CSCDCCUnpacker::produce(), HcalTBSource::produce(), ESDigiToRaw::produce(), ScaleCorrMETData::produce(), ZdcSimpleReconstructor::produce(), reco::ParticleFlowForChargedMETProducer::produce(), L3MuonSumCaloPFIsolationProducer::produce(), CaloMuonMerger::produce(), PFConversionProducer::produce(), PFV0Producer::produce(), FastTrackerRecHitCombiner::produce(), StoreSecondary::produce(), RHStopTracer::produce(), SimHitTPAssociationProducer::produce(), pat::helper::AnythingToValueMap< Adaptor, Collection, value_type >::produce(), TtSemiLepHitFitProducer< LeptonCollection >::produce(), IsoTracks::produce(), HLTHcalTowerNoiseCleanerWithrechit::produce(), HLTHcalTowerNoiseCleaner::produce(), JetTracksAssociationToTrackRefs::produce(), EgammaElectronTkNumIsolationProducer::produce(), ElectronIDExternalProducer< algo >::produce(), PUFilter::produce(), PileupJPTJetIdProducer::produce(), CaloTowerCandidateCreator::produce(), CaloTowersCreator::produce(), CaloMuonProducer::produce(), TSGFromL1Muon::produce(), TSGFromL2Muon::produce(), PFRecHitProducer::produce(), PFElectronTranslator::produce(), reco::modulesNew::MCTruthCompositeMatcher::produce(), PFTauViewRefMerger::produce(), CandViewRefTriggerBiasRemover::produce(), PixelTracksProducer::produce(), JetVetoedTracksAssociatorAtVertex::produce(), ConeIsolation::produce(), JetTagProducer::produce(), MixedGenMEtProducer::produce(), EgammaHLTCaloTowerProducer::produce(), EgammaEcalPFClusterIsolationProducer< T1 >::produce(), EgammaHcalPFClusterIsolationProducer< T1 >::produce(), GEDPhotonCoreProducer::produce(), SiStripProcessedRawDigiProducer::produce(), GEMCSCSegmentProducer::produce(), JetCoreClusterSplitter::produce(), NtpProducer< C >::produce(), MuonRefProducer::produce(), RecoTauPiZeroUnembedder::produce(), FastTSGFromL2Muon::produce(), pat::PATGenJetSlimmer::produce(), pat::PATMuonSlimmer::produce(), LmfSource::produce(), AlignmentPrescaler::produce(), edm::CosMuoGenProducer::produce(), ProbeMulteplicityProducer::produce(), ElectronPATIdMVAProducer::produce(), SelectReplacementCandidates::produce(), TtSemiEvtSolutionMaker::produce(), PreshowerClusterShapeProducer::produce(), ReducedESRecHitCollectionProducer::produce(), ZMuMuTrackUserData::produce(), bestPVselector< T1 >::produce(), CastorDigiToRaw::produce(), MVAJetPuIdProducer::produce(), EcalRecHitProducer::produce(), PreshowerPhiClusterProducer::produce(), TtSemiLepSignalSelMVAComputer::produce(), L1TTwinMuxProducer::produce(), HLTMuonL2SelectorForL3IO::produce(), MuonLinksProducerForHLT::produce(), MuonSelectionTypeValueMapProducer::produce(), PFMultiDepthClusterProducer::produce(), PreshowerClusterProducer::produce(), CandReducer::produce(), TtSemiLepJetCombMVAComputer::produce(), pat::PATElectronSlimmer::produce(), pat::PATJetSlimmer::produce(), FastTrackerRecHitMaskProducer::produce(), CosmicSeedGenerator::produce(), GEMDigiProducer::produce(), GEMPadDigiProducer::produce(), ConstrainedFitCandProducer< Fitter, InputCollection, OutputCollection, Init >::produce(), StripCompactDigiSimLinksProducer::produce(), GenTrackMatcher::produce(), TtHadEvtSolutionMaker::produce(), SiPixelFedFillerWordEventNumber::produce(), DTNewROS8FileReader::produce(), CandidateTriggerObjectProducer::produce(), HcalDigiToRaw::produce(), HcalHistogramRawToDigi::produce(), reco::modules::MatcherBase< C1, C2, M >::produce(), reco::modulesNew::Matcher< C1, C2, S, D >::produce(), ZMuMuMuonUserData::produce(), PFClusterProducer::produce(), CloneProducer< C >::produce(), RawDataSelector::produce(), PFDisplacedVertexProducer::produce(), ShallowCloneProducer< C >::produce(), L2TauPixelIsoTagProducer::produce(), FRDStreamSource::produce(), TauGenJetProducer::produce(), RecoTauPiZeroFlattener::produce(), pat::PATPhotonSlimmer::produce(), PuppiPhoton::produce(), ColinsSoperVariablesComputer::produce(), LHECOMWeightProducer::produce(), ObjectMultiplicityCounter< T >::produce(), TrackInfoProducer::produce(), TrackerHitProducer::produce(), HLTPFJetIDProducer::produce(), OtherObjectVariableComputer< T >::produce(), edm::MCFileSource::produce(), photonIsolationHIProducer::produce(), DTTrackFinder::produce(), HGCalRecHitProducer::produce(), cms::MuonMET::produce(), L1TMuonBarrelTrackProducer::produce(), RPCPackingModule::produce(), SiPixelClusterShapeCacheProducer::produce(), BeamSpotProducer::produce(), TrackFromPVSelector::produce(), RPCDigiProducer::produce(), MuonFromPVSelector::produce(), ZMuMuUserDataOneTrack::produce(), ZMuMuUserData::produce(), ElectronRecalibSuperClusterAssociator::produce(), EgammaHLTPixelMatchElectronProducers::produce(), EgammaHLTPixelMatchVarProducer::produce(), EgammaHLTRecoEcalCandidateProducers::produce(), BaseEvtVtxGenerator::produce(), CastorRawToDigi::produce(), ParticleTowerProducer::produce(), DTROS8FileReader::produce(), reco::CorrectedJetProducer< T >::produce(), QjetsAdder::produce(), EcalDCCTBUnpackingModule::produce(), JVFJetIdProducer::produce(), GlobalTrackQualityProducer::produce(), MuonLinksProducer::produce(), PFDisplacedVertexCandidateProducer::produce(), RPCUnpackingModule::produce(), TkAlCaOverlapTagger::produce(), GenParticleProducer::produce(), DeltaBetaWeights::produce(), pat::PATLostTracks::produce(), pat::RecoMETExtractor::produce(), ShiftedMETcorrInputProducer::produce(), CandViewCountEventSelFlagProducer::produce(), TotemRPRecHitProducer::produce(), DTDDUFileReader::produce(), EcalDCCTB07UnpackingModule::produce(), cms::JetVertexAssociation::produce(), EcalDetIdToBeRecoveredProducer::produce(), HcalRawToDigi::produce(), CollectionCombiner< Collection >::produce(), pat::GenMETExtractor::produce(), reco::tautools::CopyProducer< Collection >::produce(), BeamSpotOnlineProducer::produce(), NearbyCandCountComputer::produce(), L1ExtraMEtMixerPlugin::produce(), EcalListOfFEDSProducer::produce(), SubdetFEDSelector::produce(), PiZeroDiscriminatorProducer::produce(), EgammaHLTCombinedIsolationProducer::produce(), HLTCaloTowerHtMhtProducer::produce(), EgammaHLTPFChargedIsolationProducer::produce(), EgammaHLTRemoveDuplicatedSC::produce(), ESListOfFEDSProducer::produce(), ME0MuonTrackCollProducer::produce(), RandomEngineStateProducer::produce(), DTROS25FileReader::produce(), MuonMETcorrInputProducer::produce(), L1GctInternJetProducer::produce(), CSCRecHitDProducer::produce(), TopBottomClusterInfoProducer::produce(), TriggerObjectFilterByCollection::produce(), TauJetSelectorForHLTTrackSeeding::produce(), citk::PFIsolationSumProducerForPUPPI::produce(), TotemRPClusterProducer::produce(), MuonReSeeder::produce(), pat::PATTrackAndVertexUnpacker::produce(), pat::MatcherUsingTracks::produce(), LaserAlignmentProducer::produce(), DummyBoolEventSelFlagProducer::produce(), HLTDisplacedmumumuVtxProducer::produce(), EcalSimHitsValidProducer::produce(), MuonDetRecHitMixer< T1, T2 >::produce(), EgammaHLTClusterShapeProducer::produce(), EgammaHLTElectronCombinedIsolationProducer::produce(), EgammaHLTPFNeutralIsolationProducer::produce(), EgammaHLTPFPhotonIsolationProducer::produce(), VersionedIdProducer< PhysicsObjectPtr, SelectorType >::produce(), PhotonCoreProducer::produce(), DTSpyReader::produce(), cms::JetCorrectionProducer< T >::produce(), SysShiftMETcorrInputProducer::produce(), edm::FwdPtrProducer< T, H >::produce(), SiPixelDigiToRaw::produce(), ImpactParameter::produce(), PFMET::produce(), pat::PATTriggerObjectStandAloneUnpacker::produce(), Type1PFMET::produce(), ShiftedJetProducerByMatchedObjectT< T >::produce(), ShiftedParticleMETcorrInputProducer::produce(), PuppiProducer::produce(), MuonCaloDistanceProducer::produce(), ZmumuEvtSelEffCorrWeightProducer::produce(), SiStripRegFEDSelector::produce(), MuonDetCleaner::produce(), EgammaHLTEcalRecIsolationProducer::produce(), HLTEcalPFClusterIsolationProducer< T1 >::produce(), ConversionTrackMerger::produce(), CSCDigiToRawModule::produce(), CSCTFPacker::produce(), InputGenJetsParticleSelector::produce(), Type0PFMETcorrInputProducer::produce(), edm::ProductFromFwdPtrProducer< T, H >::produce(), MuonShowerInformationProducer::produce(), pat::L1MuonMatcher::produce(), cms::ReconstructerFP420::produce(), HLTDisplacedmumuVtxProducer::produce(), SiPixelRawToDigi::produce(), CaloRecoTauProducer::produce(), sistrip::DigiToRawModule::produce(), PFRecoTauProducer::produce(), HcalTBObjectUnpacker::produce(), OscarMTProducer::produce(), pat::PATVertexAssociationProducer::produce(), DigiSimLinkProducer::produce(), ElectronConversionRejectionVars::produce(), pat::DuplicatedElectronCleaner::produce(), SoftPFMuonTagInfoProducer::produce(), EgammaHLTRegionalPixelSeedGeneratorProducers::produce(), HLTMETCleanerUsingJetID::produce(), HLTHcalPFClusterIsolationProducer< T1 >::produce(), HLTMhtProducer::produce(), TtFullHadHypothesis::produce(), HLTTauMCProducer::produce(), reco::tautools::CastedRefProducer< DerivedCollection, BaseType >::produce(), PFCandMETcorrInputProducer::produce(), GsfElectronFromPVSelector::produce(), TSGForOI::produce(), pat::HLTL1MuonMatcher::produce(), PFRecoTauTagInfoProducer::produce(), SimpleTrackListMerger::produce(), TrackListMerger::produce(), TriggerSummaryProducerRAW::produce(), SoftPFElectronTagInfoProducer::produce(), L1ExtraMixerPluginT< T >::produce(), HLTHtMhtProducer::produce(), EgammaEcalRecHitIsolationProducer::produce(), EgammaTowerIsolationProducer::produce(), ShiftedPFCandidateProducerByMatchedObject::produce(), ZllArbitrator< T1 >::produce(), DTTFFEDSim::produce(), MultShiftMETcorrInputProducer::produce(), Merger< InputCollection, OutputCollection, P >::produce(), NoPileUpPFMEtProducer::produce(), GtPsbTextToDigi::produce(), PFTrackProducer::produce(), PixelVertexProducer::produce(), DaqFakeReader::produce(), RecoTauJetRegionProducer::produce(), PFTauMVAInputDiscriminantTranslator::produce(), DeDxHitInfoProducer::produce(), MuonPFCandidateCleaner::produce(), EmptyHepMCProducer::produce(), HSCPDeDxInfoProducer::produce(), ReducedRecHitCollectionProducer::produce(), HLTCaloJetIDProducer::produce(), EgammaHLTElectronDetaDphiProducer::produce(), EgammaHLTElectronTrackIsolationProducers::produce(), EgammaHLTHcalIsolationDoubleConeProducers::produce(), EleIsoDetIdCollectionProducer::produce(), CaloRecoTauTagInfoProducer::produce(), MatchedProbeMaker< T >::produce(), PFchsMETcorrInputProducer::produce(), DTTrigProd::produce(), L1TTwinMuxRawToDigi::produce(), PFClusterShapeProducer::produce(), PFLinker::produce(), EcalIsolatedParticleCandidateProducer::produce(), SiStripElectronProducer::produce(), CaloTowerFromL1TCreatorForTauHLT::produce(), edm::CFWriter::produce(), TtSemiLepHypothesis::produce(), pat::PATJetUpdater::produce(), pat::PATPackedCandidateProducer::produce(), TrackingMaterialProducer::produce(), edm::BeamHaloProducer::produce(), HLTDisplacedtktkVtxProducer::produce(), TrackAssociatorEDProducer::produce(), ClusterTPAssociationProducer::produce(), MuonRadiationCorrWeightProducer::produce(), EmbeddingKineReweightProducer::produce(), GenParticlesFromZsSelectorForMCEmbedding::produce(), TotemRPLocalTrackFitter::produce(), MCParticleReplacer::produce(), HLTmumutktkVtxProducer::produce(), CaloTowerCreatorForTauHLT::produce(), WMuNuProducer::produce(), ConvertedPhotonProducer::produce(), LaserAlignmentT0Producer::produce(), CSCTFUnpacker::produce(), ZdcHitReconstructor::produce(), L1TGlobalProducer::produce(), L1RCTTPGProvider::produce(), CosmicsMuonIdProducer::produce(), cms::TrackerizerFP420::produce(), citk::PFIsolationSumProducer::produce(), TagProbeMassProducer::produce(), FastTrackerRecHitMatcher::produce(), HLTCollectionProducer< T >::produce(), ShiftedPFCandidateProducerForPFMVAMEt::produce(), ClusterCompatibilityProducer::produce(), AlCaEcalHcalReadoutsProducer::produce(), DTTFFEDReader::produce(), MixEvtVtxGenerator::produce(), HLTTrackClusterRemoverNew::produce(), MuonCaloCleanerByDistance::produce(), EgammaSCCorrectionMaker::produce(), L1TMuonQualityAdjuster::produce(), EgammaHLTHcalIsolationProducersRegional::produce(), IsolationProducer< C1, C2, Alg, OutputCollection, Setup >::produce(), TtEvtBuilder< C >::produce(), CosmicTrackSelector::produce(), ConversionSeedFilterCharge::produce(), edm::LogErrorHarvester::produce(), JetSubstructurePacker::produce(), ShiftedParticleProducer::produce(), PFCTRecHitProducer::produce(), EgammaHLTBcHcalIsolationProducersRegional::produce(), EgammaHLTR9IDProducer::produce(), TtFullLepHypothesis::produce(), HLTL1TMuonSelector::produce(), ZToLLEdmNtupleDumper::produce(), JetCorrectorProducer< T >::produce(), CSCTriggerPrimitivesProducer::produce(), L1GctEmulator::produce(), EcalRecHitRecalib::produce(), AlCaElectronTracksReducer::produce(), L1ExtraParticleMapProd::produce(), HcalRecHitRecalib::produce(), MuonCaloCleanerAllCrossed::produce(), PartonSelector::produce(), pat::PATConversionProducer::produce(), edm::TriggerResultInserter::produce(), Onia2MuMuPAT::produce(), ECALRegFEDSelector::produce(), V0Producer::produce(), EgammaHLTPhotonTrackIsolationProducersRegional::produce(), HLTRechitInRegionsProducer< T1 >::produce(), AlCaDiJetsProducer::produce(), ConversionTrackCandidateProducer::produce(), NTuplingDevice::produce(), PrimaryVertexSorter< ParticlesCollection >::produce(), VoronoiBackgroundProducer::produce(), PFCand_AssoMap::produce(), L1EmulBias::produce(), SeedClusterRemover::produce(), SimG4HcalValidation::produce(), PFPileUp::produce(), RctTextToRctDigi::produce(), modules::MuonCleanerBySegmentsT< T >::produce(), HiEgammaSCCorrectionMaker::produce(), BtoCharmDecayVertexMergerT< VTX >::produce(), PATHemisphereProducer::produce(), pat::PATMETProducer::produce(), SiStripFineDelayHit::produce(), pat::PATPackedGenParticleProducer::produce(), EcalTrigPrimProducer::produce(), pat::__class__Producer::produce(), TrackMVAClassifierBase::produce(), EgammaHLTR9Producer::produce(), GamIsoDetIdCollectionProducer::produce(), reco::modulesNew::IsolationProducer< C1, C2, Alg, OutputCollection, Setup >::produce(), PhotonProducer::produce(), cms::ClusterizerFP420::produce(), AlCaGammaJetProducer::produce(), pat::PATCleaner< PATObjType >::produce(), cms::MuonMETValueMapProducer::produce(), L1TMuonTriggerPrimitiveProducer::produce(), NeutronHitsCollector::produce(), FakeTrackProducer< T >::produce(), EcalFEtoDigi::produce(), HLTmumutkVtxProducer::produce(), ScalersRawToDigi::produce(), HBHENoiseFilterResultProducer::produce(), HLTScoutingCaloProducer::produce(), HLTJetCollectionsForBoostedLeptonPlusJets< jetType >::produce(), ConversionSeedFilter::produce(), HLTJetCollectionsForLeptonPlusJets< jetType >::produce(), HLTTrackMETProducer::produce(), RecoTauPiZeroProducer::produce(), JetPlusTrackProducer::produce(), L1ExtraParticlesProd::produce(), pat::PATCompositeCandidateProducer::produce(), HITrackClusterRemover::produce(), cms::HitReCalibrator::produce(), TextToRaw::produce(), PFProducer::produce(), TrackCandidateProducer::produce(), SiStripElectronAssociator::produce(), HLTJetCollForElePlusJets< T >::produce(), EventWithHistoryProducer::produce(), TrackMCQuality::produce(), HLTL1MuonSelector::produce(), EgammaIsoESDetIdCollectionProducer::produce(), HiGenCleaner< T2 >::produce(), CastorJetIDProducer::produce(), GctDigiToRaw::produce(), PixelVertexCollectionTrimmer::produce(), MinMETProducerT< T >::produce(), MuPFIsoEmbedder::produce(), LTCRawToDigi::produce(), simwatcher::BeginOfTrackCounter::produce(), L1TPhysicalEtAdder::produce(), TotemTestGem::produce(), DeltaRNearestObjectComputer< T >::produce(), EgammaHLTEcalIsolationProducersRegional::produce(), HLTJetCollectionsForElePlusJets< T >::produce(), PFECALSuperClusterProducer::produce(), PF_PU_AssoMap::produce(), L1DummyProducer::produce(), l1t::L1ComparatorRun2::produce(), MuonTimingProducer::produce(), TrackCandidateTopBottomHitFilter::produce(), GSFElectronsMixer::produce(), OutsideInMuonSeeder::produce(), pat::PATGenericParticleProducer::produce(), TestBXVectorRefProducer::produce(), SimpleCosmicBONSeeder::produce(), SourceCardTextToRctDigi::produce(), FromClusterSummaryMultiplicityProducer::produce(), AlCaHcalNoiseProducer::produce(), BoostedTauSeedsProducer::produce(), GEDPhotonProducer::produce(), EventWithHistoryProducerFromL1ABC::produce(), EgammaIsoHcalDetIdCollectionProducer::produce(), HLTScoutingPFProducer::produce(), NjettinessAdder::produce(), NoPileUpPFMEtDataProducer::produce(), TrackAssociatorByPositionProducer::produce(), L1GlobalTriggerRecordProducer::produce(), cms::MuonTCMETValueMapProducer::produce(), pat::PATMuonProducer::produce(), pat::PATPFParticleProducer::produce(), IsolatedPixelTrackCandidateProducer::produce(), pat::TauJetCorrFactorsProducer::produce(), HLTScoutingMuonProducer::produce(), CastorCellProducer::produce(), DTDigitizer::produce(), MaskedRctInputDigiProducer::produce(), BSCTrigger::produce(), PFSimParticleProducer::produce(), HLTRechitsToDigis::produce(), cms::DigitizerFP420::produce(), HcalTB02Analysis::produce(), ShiftedPFCandidateProducerForPFNoPUMEt::produce(), ShiftedPFCandidateProducerForNoPileUpPFMEt::produce(), ElectronSeedProducer::produce(), EcalRawToDigi::produce(), CorrectedCaloMETProducer::produce(), HcalHitSelection::produce(), EcalFEDWithCRCErrorProducer::produce(), JetIDProducer::produce(), L1Comparator::produce(), TrajectorySeedFromMuonProducer::produce(), VertexFromTrackProducer::produce(), QuickTrackAssociatorByHitsProducer::produce(), L1TMuonLegacyConverter::produce(), TrackMultiSelector::produce(), CtfSpecialSeedGenerator::produce(), HcalHitReconstructor::produce(), ExtraFromSeeds::produce(), InterestingDetIdFromSuperClusterProducer::produce(), L1TMuonOverlapTrackProducer::produce(), InterestingDetIdCollectionProducer::produce(), IsolatedPixelTrackCandidateL1TProducer::produce(), TtJetPartonMatch< C >::produce(), CorrectedPATMETProducer::produce(), pat::PATTauProducer::produce(), ConfigurableAPVCyclePhaseProducer::produce(), L1TBMTFConverter::produce(), GsfTrackMixer::produce(), ReducedEGProducer::produce(), l1t::FakeInputProducer::produce(), ElectronSeedTrackRefUpdaterAndMerger::produce(), ValueMapTraslator::produce(), HLTScoutingEgammaProducer::produce(), FFTJetPFPileupCleaner::produce(), FFTJetVertexAdder::produce(), L1MuGMTHWFileReader::produce(), CaloRecHitMixer< T >::produce(), RochesterCorrMuonProducerT< T >::produce(), reco::PFMETProducerMVA::produce(), RPCTrigger::produce(), MuScleFitMuonProducer::produce(), RecHitCorrector::produce(), TruthTauDecayModeProducer::produce(), ElectronSeedTrackRefUpdater::produce(), pat::PATJetProducer::produce(), pat::MatcherByPulls< T >::produce(), TrackAssociatorByChi2Producer::produce(), InterestingTrackEcalDetIdProducer::produce(), GenHIEventProducer::produce(), Timer::produce(), CentralityBinProducer::produce(), FFTJetPileupEstimator::produce(), MuonSegmentProducer::produce(), PF_PU_FirstVertexTracks::produce(), L1TExtCondProducer::produce(), MuonErrorMatrixAdjuster::produce(), RecoTauProducer::produce(), DeDxEstimatorProducer::produce(), CaloTowersMerger::produce(), SoftKillerProducer::produce(), L1TMuonEndCapTrackProducer::produce(), ConversionTrackProducer::produce(), HiSpikeCleaner::produce(), AlCaECALRecHitReducer::produce(), ConvBremSeedProducer::produce(), L1TMicroGMTInputProducer::produce(), PFTauSecondaryVertexProducer::produce(), EcalDigiToRaw::produce(), pat::PATTriggerMatchEmbedder< PATObjectType >::produce(), RctInputTextToDigi::produce(), TrackFromSeedProducer::produce(), PileupJetIdProducer::produce(), NuclearSeedsEDProducer::produce(), L1GlobalTriggerEvmRawToDigi::produce(), l1t::L1TCaloRCTToUpgradeConverter::produce(), CaloRecHitsBeamHaloCleaned::produce(), L1TMuonCaloSumProducer::produce(), ConditionDumperInEdm::produce(), L2MuonSeedGeneratorFromL1T::produce(), PFBlockProducer::produce(), AlCaHBHEMuonProducer::produce(), CastorTowerProducer::produce(), MultiplicityProducer< T >::produce(), CastorClusterProducer::produce(), PatJPsiProducer::produce(), L1TCaloUpgradeToGCTConverter::produce(), HiL1Subtractor::produce(), NuclearInteractionEDProducer::produce(), LHE2HepMCConverter::produce(), TrackAssociatorByHitsProducer::produce(), TauSpinnerCMS::produce(), HLTPrescaleRecorder::produce(), L1MuGlobalMuonTrigger::produce(), TcdsRawToDigi::produce(), SiTrackerGaussianSmearingRecHitConverter::produce(), L1TExtCondLegacyToStage2::produce(), MixBoostEvtVtxGenerator::produce(), ObjectViewMatcher< T1, T2 >::produce(), L1GTEvmDigiToRaw::produce(), L1GtTextToRaw::produce(), PrimaryVertexProducer::produce(), FFTJetEFlowSmoother::produce(), reco::HcalNoiseInfoProducer::produce(), EcalSimpleProducer::produce(), JetDeltaRTagInfoValueMapProducer< T, I >::produce(), BetaBoostEvtVtxGenerator::produce(), SiStripMeanCMExtractor::produce(), GenJetBCEnergyRatio::produce(), PFRecoTauChargedHadronProducer::produce(), L1TMicroGMTInputProducerFromGen::produce(), PFCand_NoPU_WithAM::produce(), pat::PATPhotonProducer::produce(), L2MuonSeedGenerator::produce(), JetPlusTrackProducerAA::produce(), reco::CentralityProducer::produce(), pat::PATElectronProducer::produce(), SiPixelClusterProducer::produce(), pat::PATTriggerEventProducer::produce(), CorrectedECALPFClusterProducer::produce(), l1t::AMC13DumpToRaw::produce(), l1t::AMCDumpToRaw::produce(), AlignmentMuonHIPTrajectorySelector::produce(), SiPixelCalibDigiProducer::produce(), TrackAlgoCompareUtil::produce(), L1GTDigiToRaw::produce(), SeedToTrackProducer::produce(), FFTJetPileupProcessor::produce(), HighPtTrackEcalDetIdProducer::produce(), FastPrimaryVertexWithWeightsProducer::produce(), HcalTB04Analysis::produce(), reco::modules::TrackFullCloneSelectorBase< Selector >::produce(), ObjectViewCleaner< T >::produce(), reco::modules::HICaloCompatibleTrackSelector::produce(), RecoTauCleanerImpl< Prod >::produce(), BoostedJetMerger::produce(), APVCyclePhaseProducerFromL1ABC::produce(), L1GlobalTrigger::produce(), PFTauTransverseImpactParameters::produce(), PixelJetPuId::produce(), TrackExtrapolator::produce(), PFEGammaProducer::produce(), L1GlobalTriggerRawToDigi::produce(), APVCyclePhaseProducerFromL1TS::produce(), L1TStage2Layer2Producer::produce(), CorrectedPFMETProducer::produce(), PFPhotonTranslator::produce(), FlavorHistoryProducer::produce(), reco::BeamHaloSummaryProducer::produce(), L1TMuonProducer::produce(), sistrip::FEDEmulatorModule::produce(), l1t::MP7BufferDumpToRaw::produce(), L1TCaloLayer1::produce(), GenHFHadronMatcher::produce(), l1t::GenToInputProducer::produce(), JetIdSelector< T >::produce(), l1t::BXVectorInputProducer::produce(), ShiftedParticleProducerT< T >::produce(), ShallowGainCalibration::produce(), pat::PATTriggerProducer::produce(), HiEvtPlaneFlatProducer::produce(), ReduceHcalRecHitCollectionProducer::produce(), TrackerToMuonPropagator::produce(), pat::PATMHTProducer::produce(), TrackClusterSplitter::produce(), CSCOverlapsTrackPreparation::produce(), PFElecTkProducer::produce(), EgammaHLTGsfTrackVarProducer::produce(), CATopJetTagger::produce(), ME0MuonConverter::produce(), reco::PhysObjectMatcher< C1, C2, S, D, Q >::produce(), JetDeltaRValueMapProducer< T, C >::produce(), L1TStage2Layer1Producer::produce(), pat::helper::ManyThingsToValueMaps< Adaptor, Collection, value_type >::produce(), JetCrystalsAssociator::produce(), MuonIdProducer::produce(), ExternalLHEProducer::produce(), PFTauPrimaryVertexProducer::produce(), ProduceIsolationMap::produce(), MuonMCClassifier::produce(), ClusterSummaryProducer::produce(), ConversionProducer::produce(), cms::CosmicTrackFinder::produce(), HLTDummyCollections::produce(), L1TCaloLayer1RawToDigi::produce(), FFTJetPatRecoProducer::produce(), cms::SiPixelRecHitConverter::produce(), reco::modules::TrackerTrackHitFilter::produce(), RPCTechnicalTrigger::produce(), L1TStage1Layer2Producer::produce(), MuonSimHitProducer::produce(), FastPrimaryVertexProducer::produce(), reco::modules::CosmicTrackSplitter::produce(), HepMCSplitter::produce(), GoodSeedProducer::produce(), GenTtbarCategorizer::produce(), HLTJetsCleanedFromLeadingLeptons< JetType >::produce(), ME0SegmentMatcher::produce(), GlobalHitsProducer::produce(), HadronAndPartonSelector::produce(), TrajectorySeedProducer::produce(), NuclearTrackCorrector::produce(), PFTau3ProngReco::produce(), TriggerSummaryProducerAOD::produce(), CandidateProducer< TColl, CColl, Selector, Conv, Creator, Init >::produce(), BoostedTopProducer::produce(), SelectedElectronFEDListProducer< TEle, TCand >::produce(), ShiftedJetProducerT< T, Textractor >::produce(), reco::HcalHaloDataProducer::produce(), RPCSeedGenerator::produce(), AlCaIsoTracksProducer::produce(), CorrectedMETProducerT< T >::produce(), reco::modules::JetFlavourIdentifier::produce(), JetPartonMatcher::produce(), reco::EcalHaloDataProducer::produce(), CaloJetMETcorrInputProducerT< T, Textractor >::produce(), Type2CorrectionProducer::produce(), GlobalDigisProducer::produce(), SimHitShifter::produce(), ChainedJetCorrectorProducer::produce(), JetCleanerForType1METT< T, Textractor >::produce(), reco::modules::NamedCandCombiner< Selector, PairSelector, Cloner, Setup, Init >::produce(), reco::CSCHaloDataProducer::produce(), IPProducer< Container, Base, Helper >::produce(), reco::modules::CandCombiner< Selector, PairSelector, Cloner, OutputCollection, Setup, Init >::produce(), JetFlavourClustering::produce(), PFJetMETcorrInputProducerT< T, Textractor >::produce(), edm::HiMixingModule::produce(), TopProjector< Top, Bottom, Matcher >::produce(), GlobalRecHitsProducer::produce(), AlCaHOCalibProducer::produce(), EvtPlaneProducer::produce(), MuonToTrackingParticleAssociatorEDProducer::produce(), reco::GlobalHaloDataProducer::produce(), SiStripClusterizerFromRaw::produce(), cms::CkfTrackCandidateMakerBase::produceBase(), L1GlobalTriggerEvmRawToDigi::produceEmptyProducts(), L1GlobalTriggerRawToDigi::produceEmptyProducts(), SiStripFineDelayHit::produceNoTracking(), Multi5x5SuperClusterProducer::produceSuperclustersForECALPart(), HiSuperClusterProducer::produceSuperclustersForECALPart(), GlobalMuonTrackMixer::produceTrackExtras(), GlobalMuonTrackCleaner::produceTrackExtras(), TeVMuonTrackCleaner::produceTrackExtras(), TeVMuonTrackMixer::produceTrackExtras(), FastjetJetProducer::produceTrackJets(), TrackMixerBase::produceTracks(), MuonTrackCleanerBase::produceTracks(), put(), helper::CandDecayStoreManager::put(), helper::PhotonCollectionStoreManager::put(), helper::MuonCollectionStoreManager::put(), helper::TrackCollectionStoreManager::put(), helper::GsfElectronCollectionStoreManager::put(), edm::MixingModule::put(), helper::CollectionStoreManager< OutputCollection, ClonePolicy >::put(), put(), edm::MixingWorker< T >::put(), edm::DataMixingEMWorker::putEM(), edm::DataMixingEMDigiWorker::putEM(), GtPsbTextToDigi::putEmptyDigi(), RctTextToRctDigi::putEmptyDigi(), SourceCardTextToRctDigi::putEmptyDigi(), TextToRaw::putEmptyDigi(), edm::DataMixingGeneralTrackWorker::putGeneralTrack(), edm::DataMixingHcalWorker::putHcal(), edm::DataMixingHcalDigiWorker::putHcal(), QGTagger::putInEvent(), KfTrackProducerBase::putInEvt(), GsfTrackProducerBase::putInEvt(), TrackProducerWithSCAssociation::putInEvt(), DAFTrackProducer::putInEvtTrajAnn(), edm::DataMixingMuonWorker::putMuon(), edm::DataMixingPileupCopy::putPileupInfo(), edm::DataMixingSiPixelWorker::putSiPixel(), edm::DataMixingSiPixelMCDigiWorker::putSiPixel(), edm::DataMixingSiStripWorker::putSiStrip(), edm::DataMixingSiStripRawWorker::putSiStrip(), edm::DataMixingSiStripMCDigiWorker::putSiStrip(), edm::DataMixingTrackingParticleWorker::putTrackingParticle(), AnalyticalTrackSelector::run(), MultiTrackSelector::run(), HIMultiTrackSelector::run(), FFTJetProducer::saveResults(), SiStripZeroSuppression::StandardZeroSuppression(), PixelTrackProducer::store(), pat::L1MuonMatcher::storeExtraInfo(), pat::HLTL1MuonMatcher::storeExtraInfo(), pat::MatcherUsingTracks::storeValueMap(), TriggerMatcherToHLTDebug::storeValueMap(), L1GlobalTriggerRawToDigi::unpackGMT(), SubjetFilterJetProducer::writeCompoundJets(), cms::CompoundJetProducer::writeCompoundJets(), VirtualJetProducer::writeCompoundJets(), VirtualJetProducer::writeJets(), FFTJetProducer::writeJets(), ElectronIDValueMapProducer::writeValueMap(), MVAValueMapProducer< ParticleType >::writeValueMap(), PhotonIDValueMapProducer::writeValueMap(), PhotonRegressionValueMapProducer::writeValueMap(), ElectronRegressionValueMapProducer::writeValueMap(), MuonMCClassifier::writeValueMap(), l1t::stage2::BMTFCollections::~BMTFCollections(), l1t::stage2::CaloCollections::~CaloCollections(), l1t::stage1::CaloCollections::~CaloCollections(), l1t::stage2::EMTFCollections::~EMTFCollections(), GctUnpackCollections::~GctUnpackCollections(), l1t::stage2::GMTCollections::~GMTCollections(), l1t::stage2::GTCollections::~GTCollections(), and RctUnpackCollections::~RctUnpackCollections().
|
inline |
Definition at line 125 of file Event.h.
References eostools::move(), and AlCaHLTBitMon_QueryRunRegistry::string.
OrphanHandle< PROD > Event::put | ( | std::auto_ptr< PROD > | product, |
std::string const & | productInstanceName | ||
) |
Put a new product with a 'product instance name'.
Definition at line 365 of file Event.h.
References put().
OrphanHandle< PROD > Event::put | ( | std::unique_ptr< PROD > | product, |
std::string const & | productInstanceName | ||
) |
Definition at line 370 of file Event.h.
References edm::RecordInParentfull< PROD >::do_it(), edm::PrincipalGetAdapter::getBranchDescription(), makeProductID(), eostools::move(), PROD, parseEventContent::prod, provRecorder_, putProducts(), putProductsWithoutParents(), edm::principal_get_adapter_detail::throwOnPutOfNullProduct(), and relativeConstraints::value.
|
inlineprivate |
|
inlineprivate |
|
inlineprivate |
Definition at line 269 of file Event.h.
References putProductsWithoutParents_.
Referenced by commit_(), put(), and size().
|
inlineprivate |
Definition at line 271 of file Event.h.
References putProductsWithoutParents_.
|
inline |
Definition at line 93 of file Event.h.
References edm::EventBase::id(), and edm::EventID::run().
Referenced by RawDataConverter::analyze(), ZeePlots::analyze(), RecAnalyzerMinbias::analyze(), WenuPlots::analyze(), L1GtPatternGenerator::analyze(), HLTrigReport::analyze(), cms::Analyzer_minbias::analyze(), APVCyclePhaseMonitor::analyze(), l1t::L1TStage2CaloAnalyzer::analyze(), BigEventsDebugger< T >::analyze(), AnalyzerMinbias::analyze(), BeamHaloAnalyzer::analyze(), L1GtAnalyzer::analyzeConditionsInEventBlock(), L1GtAnalyzer::analyzeL1GtUtilsCore(), GlobalTrackerMuonAlignment::analyzeTrackTrack(), GlobalTrackerMuonAlignment::analyzeTrackTrajectory(), L1GtAnalyzer::analyzeTrigger(), Types.EventID::cppID(), Types.LuminosityBlockID::cppID(), LogErrorEventFilter::filter(), ZeeCandidateFilter::filter(), MatacqProducer::getRunNumber(), BunchSpacingProducer::produce(), HcalSimpleReconstructor::produce(), sistrip::ExcludedFEDListProducer::produce(), EventWithHistoryProducerFromL1ABC::produce(), HcalHitReconstructor::produce(), APVCyclePhaseProducerFromL1ABC::produce(), APVCyclePhaseProducerFromL1TS::produce(), CtfSpecialSeedGenerator::run(), MuScleFit::selectMuons(), L1Analysis::L1AnalysisL1Menu::SetPrescaleFactorIndex(), and LaserSorter::writeEventHeader().
void Event::setConsumer | ( | EDConsumerBase const * | iConsumer | ) |
Definition at line 37 of file Event.cc.
References luminosityBlock_, provRecorder_, and edm::PrincipalGetAdapter::setConsumer().
Referenced by edm::EDAnalyzer::doEvent(), edm::EDProducer::doEvent(), edm::EDFilter::doEvent(), edm::global::EDAnalyzerBase::doEvent(), edm::global::EDFilterBase::doEvent(), edm::one::EDProducerBase::doEvent(), edm::one::EDFilterBase::doEvent(), edm::global::EDProducerBase::doEvent(), edm::one::EDAnalyzerBase::doEvent(), edm::stream::EDProducerAdaptorBase::doEvent(), edm::stream::EDFilterAdaptorBase::doEvent(), and edm::stream::EDAnalyzerAdaptorBase::doEvent().
void Event::setSharedResourcesAcquirer | ( | SharedResourcesAcquirer * | iResourceAcquirer | ) |
Definition at line 43 of file Event.cc.
References luminosityBlock_, provRecorder_, and edm::PrincipalGetAdapter::setSharedResourcesAcquirer().
Referenced by edm::EDAnalyzer::doEvent(), edm::EDProducer::doEvent(), edm::EDFilter::doEvent(), edm::one::EDFilterBase::doEvent(), edm::one::EDProducerBase::doEvent(), and edm::one::EDAnalyzerBase::doEvent().
size_t Event::size | ( | void | ) | const |
Definition at line 192 of file Event.cc.
References edm::PrincipalGetAdapter::principal(), provRecorder_, putProducts(), putProductsWithoutParents(), and edm::Principal::size().
Referenced by LaserSorter::writeEvent().
|
inline |
Definition at line 80 of file Event.h.
References streamID_.
Referenced by HcalDigiProducer::accumulate(), HGCDigiProducer::accumulate(), CastorDigiProducer::accumulate(), HcalTBDigiProducer::accumulate(), SiStripDigitizer::accumulate(), cms::SiPixelDigitizer::accumulate(), EcalDigiProducer::accumulate(), GenMuonRadCorrAnalyzer::analyze(), edm::SecSourceAnalyzer::analyze(), EcalMixingModuleValidation::analyze(), edm::global::EDAnalyzerBase::doEvent(), edm::global::EDFilterBase::doEvent(), edm::global::EDProducerBase::doEvent(), edm::DataMixingModule::doPileUp(), edm::MixingModule::doPileUp(), GaussianZBeamSpotFilter::filter(), TauSpinnerFilter::filter(), edm::RandomFilter::filter(), PythiaFilterIsolatedTrack::filter(), edm::GeneratorFilter< HAD, DEC >::filter(), HiCentralityBiasFilter::filter(), edm::HadronizerFilter< HAD, DEC >::filter(), HLTLogMonitorFilter::filter(), HcalDigiProducer::finalizeEvent(), HGCDigiProducer::finalizeEvent(), CastorDigiProducer::finalizeEvent(), HcalTBDigiProducer::finalizeEvent(), SiStripDigitizer::finalizeEvent(), cms::SiPixelDigitizer::finalizeEvent(), EcalDigiProducer::finalizeEvent(), MCParticleReplacer::getStreamID(), edm::service::RandomNumberGeneratorService::postEventRead(), edm::FlatRandomPtThetaGunProducer::produce(), edm::FlatRandomEThetaGunProducer::produce(), edm::FileRandomKEThetaGunProducer::produce(), CSCDigiProducer::produce(), edm::FlatRandomOneOverPtGunProducer::produce(), edm::FlatRandomPtGunProducer::produce(), CalibratedPhotonProducerRun2T< T >::produce(), edm::FlatRandomEGunProducer::produce(), edm::MultiParticleInConeGunProducer::produce(), edm::ExpoRandomPtGunProducer::produce(), CalibratedPatElectronProducer::produce(), HectorProducer::produce(), FamosProducer::produce(), edm::ExpoRandomPGunProducer::produce(), ME0DigiPreRecoProducer::produce(), CalibratedElectronProducerRun2T< T >::produce(), OscarProducer::produce(), edm::CosMuoGenProducer::produce(), GEMDigiProducer::produce(), CalibratedElectronProducer::produce(), RPCDigiProducer::produce(), BaseEvtVtxGenerator::produce(), QjetsAdder::produce(), RandomEngineStateProducer::produce(), OscarMTProducer::produce(), DigiSimLinkProducer::produce(), SubsystemNeutronWriter::produce(), EcalTBMCInfoProducer::produce(), edm::BeamHaloProducer::produce(), edm::LogErrorHarvester::produce(), L1EmulBias::produce(), RunManagerMTWorker::produce(), L1DummyProducer::produce(), DTDigitizer::produce(), gen::Pythia6Gun::produce(), FFTJetVertexAdder::produce(), SiTrackerGaussianSmearingRecHitConverter::produce(), TauSpinnerCMS::produce(), BetaBoostEvtVtxGenerator::produce(), MuonSimHitProducer::produce(), edm::DataMixingSiPixelMCDigiWorker::putSiPixel(), edm::DataMixingSiStripMCDigiWorker::putSiStrip(), edm::service::RandomNumberGeneratorService::readFromEvent(), and IsoTrig::studyTiming().
|
virtual |
Implements edm::EventBase.
Definition at line 215 of file Event.cc.
References Exception, cscdqm::h::names, and edm::EventBase::triggerNames_().
Referenced by HcalNZSMonitor::analyze(), CaloTowerAnalyzer::analyze(), EventShapeDQM::analyze(), HeavyIonUCCDQM::analyze(), EwkMuDQM::analyze(), DQMHcalIsolatedBunchAlCaReco::analyze(), EwkElecDQM::analyze(), SUSY_HLT_InclusiveHT::analyze(), SUSY_HLT_PhotonHT::analyze(), SUSY_HLT_PhotonMET::analyze(), HLTInspect::analyze(), SUSY_HLT_DoubleMuon_Hadronic::analyze(), QcdPhotonsDQM::analyze(), HTMHTAnalyzer::analyze(), SUSY_HLT_DoubleEle_Hadronic::analyze(), EwkDQM::analyze(), StudyHLT::analyze(), BeamMonitor::analyze(), SUSY_HLT_alphaT::analyze(), SUSY_HLT_DiJet_MET::analyze(), SUSY_HLT_Muon_Hadronic::analyze(), SUSY_HLT_MuEle_Hadronic::analyze(), SUSY_HLT_VBF_Mu::analyze(), TopDiLeptonDQM::analyze(), SUSY_HLT_Razor::analyze(), HotlineDQM::analyze(), AnalysisRootpleProducer::analyze(), BTVHLTOfflineSource::analyze(), HLTInclusiveVBFSource::analyze(), MuTriggerAnalyzer::analyze(), MuonRecoOneHLT::analyze(), TopSingleLeptonHLTValidation::analyze(), B2GDoubleLeptonHLTValidation::analyze(), B2GHadronicHLTValidation::analyze(), B2GSingleLeptonHLTValidation::analyze(), L1MetFilterRecoTreeProducer::analyze(), DQMExample_Step1::analyze(), TopDiLeptonHLTValidation::analyze(), HeavyFlavorValidation::analyze(), SUSY_HLT_SingleLepton::analyze(), HigPhotonJetHLTOfflineSource::analyze(), HLTJetMETValidation::analyze(), HcalRaddamMuon::analyze(), FSQDiJetAve::analyze(), HcalHBHEMuonAnalyzer::analyze(), JetMETHLTOfflineSource::analyze(), HLTHiggsSubAnalysis::analyze(), HLTScalers::analyze(), HcalIsoTrkAnalyzer::analyze(), HcalDigiMonitor::analyze(), IsoTrig::analyze(), IsoTrackCalibration::analyze(), HLTExoticaSubAnalysis::analyze(), HLTInfo::analyze(), JetAnalyzer::analyze(), ExoticaDQM::analyze(), ErsatzMEt::analyze(), IsolatedTracksCone::analyze(), GammaJetAnalysis::analyze(), HLTEventAnalyzerRAW::analyzeTrigger(), HLTEventAnalyzerAOD::analyzeTrigger(), HLTBitComputer::compute(), HLTBitVariable::eval(), AdHocNTupler::fill(), EwkElecTauHistManager::fillHistograms(), EwkMuTauHistManager::fillHistograms(), PdfSystematicsAnalyzer::filter(), SimpleSystematicsAnalyzer::filter(), HLTPathSelector::filter(), WMuNuValidator::filter(), WMuNuSelector::filter(), PhysDecl::filter(), HLTHighLevel::filter(), AlCaIsolatedBunchSelector::filter(), AlCaIsolatedBunchFilter::filter(), PrescalerFHN::filter(), AlCaHBHEMuonFilter::filter(), AlCaIsoTracksFilter::filter(), ZeeCandidateFilter::filter(), HltComparator::initialise(), ZGoldenFilter::newEvent(), HcalRecHitMonitor::processEvent(), CandidateTriggerObjectProducer::produce(), pat::PATTriggerObjectStandAloneUnpacker::produce(), pat::PATTriggerProducer::produce(), AlCaIsoTracksProducer::produce(), reco::CSCHaloDataProducer::produce(), L1Analysis::L1AnalysisEvent::Set(), egHLT::OffHelper::setTrigInfo(), GsfElectronDataAnalyzer::trigger(), and DQMAnalyzer::trigger().
|
virtual |
Implements edm::EventBase.
Definition at line 225 of file Event.cc.
References getByLabel(), edm::HandleBase::isValid(), cscdqm::h::names, edm::Handle< T >::product(), AlCaHLTBitMon_QueryRunRegistry::string, GlobalPosition_Frontier_DevDB_cff::tag, and edm::EventBase::triggerNames_().
Referenced by HSCPHLTFilter::filter(), and HSCPValidator::makeHLTPlots().
|
friend |
|
friend |
|
friend |
|
friend |
|
friend |
|
private |
Definition at line 282 of file Event.h.
Referenced by eventAuxiliary().
|
staticprivate |
Definition at line 299 of file Event.h.
Referenced by getByLabel().
|
mutableprivate |
Definition at line 290 of file Event.h.
Referenced by addToGotBranchIDs(), and commit_aux().
|
mutableprivate |
Definition at line 294 of file Event.h.
Referenced by fillView_().
|
private |
Definition at line 283 of file Event.h.
Referenced by getLuminosityBlock(), setConsumer(), and setSharedResourcesAcquirer().
|
private |
Definition at line 297 of file Event.h.
Referenced by getByLabel(), getByLabelImpl(), getByToken(), getManyByType(), getProvenance(), and moduleCallingContext().
|
private |
Definition at line 273 of file Event.h.
Referenced by eventPrincipal(), getAllProvenance(), getByLabel(), getByLabelImpl(), getByToken(), getManyByType(), getProvenance(), getRefBeforePut(), labelsForToken(), processHistory(), productGetter(), put(), setConsumer(), setSharedResourcesAcquirer(), and size().
|
private |
Definition at line 279 of file Event.h.
Referenced by putProducts().
|
private |
Definition at line 280 of file Event.h.
Referenced by putProductsWithoutParents().
|
private |
Definition at line 296 of file Event.h.
Referenced by streamID().