Functions | |
def | makeJobBlock |
Variables | |
string | comma = "," |
string | commandline = " " |
string | commax = "," |
tuple | comment1RE = re.compile(r'^#.+$') |
list | commentLines = [] |
list | copyargs = sys.argv[:] |
int | default = 0 |
string | dest = "debug" |
list | eventsFiles = [] |
tuple | evtPerJob = int(math.ceil(float(ntotal)/NBLOCKS)) |
tuple | fileLineRE = re.compile(r'^.*\'(.*)\'.+# (\d*).*$') |
tuple | fin = open(INFILE, "r") |
tuple | fout = open(OUTFILE, mode="w") |
string | help = "debug verbosity level" |
list | INFILE = sys.argv[2] |
list | jobsBlocks = [] |
tuple | lines = fin.readlines() |
tuple | match = comment1RE.match(line) |
tuple | NBLOCKS = int(sys.argv[1]) |
int | ntotal = 0 |
list | OUTFILE = sys.argv[3] |
tuple | parser = optparse.OptionParser(usage) |
To parse commandline args. More... | |
list | prog = sys.argv[0] |
temp = eventsFiles | |
int | tt = 0 |
string | type = "int" |
string | usage = './%(prog)s NBLOCKS INFILE OUTFILE [options]\n' |
def groupFilesInBlocks.makeJobBlock | ( | mylist, | |
evtn | |||
) |
Definition at line 46 of file groupFilesInBlocks.py.
References print(), and sistrip::SpyUtilities.range().
string groupFilesInBlocks.comma = "," |
Definition at line 175 of file groupFilesInBlocks.py.
string groupFilesInBlocks.commandline = " " |
Definition at line 14 of file groupFilesInBlocks.py.
string groupFilesInBlocks.commax = "," |
Definition at line 172 of file groupFilesInBlocks.py.
tuple groupFilesInBlocks.comment1RE = re.compile(r'^#.+$') |
Definition at line 86 of file groupFilesInBlocks.py.
list groupFilesInBlocks.commentLines = [] |
Definition at line 101 of file groupFilesInBlocks.py.
list groupFilesInBlocks.copyargs = sys.argv[:] |
Definition at line 8 of file groupFilesInBlocks.py.
int groupFilesInBlocks.default = 0 |
Definition at line 32 of file groupFilesInBlocks.py.
string groupFilesInBlocks.dest = "debug" |
Definition at line 33 of file groupFilesInBlocks.py.
list groupFilesInBlocks.eventsFiles = [] |
Definition at line 99 of file groupFilesInBlocks.py.
Definition at line 134 of file groupFilesInBlocks.py.
tuple groupFilesInBlocks.fileLineRE = re.compile(r'^.*\'(.*)\'.+# (\d*).*$') |
Definition at line 87 of file groupFilesInBlocks.py.
tuple groupFilesInBlocks.fin = open(INFILE, "r") |
Definition at line 94 of file groupFilesInBlocks.py.
Referenced by addFile(), HIPplots.CheckFileExistence(), convertFile(), dumpFiles(), popcon::EcalLaser_weekly_Linearization_Check.getNewObjects(), ElectronEnergyCalibrator.init(), dqmservices::DQMProtobufReader.load(), main(), MuonGeometryArrange.MuonGeometryArrange(), ALIFileIn.openNewFile(), RPCPatternsParser.parse(), CommandLine.parse_file(), pos::PixelFEDTestDAC.PixelFEDTestDAC(), CSCChamberTimeCorrectionsValues.prefill(), CSCChipSpeedCorrectionDBConditions.prefillDBChipSpeedCorrection(), CSCGasGainCorrectionDBConditions.prefillDBGasGainCorrection(), CSCGasCollisions.readCollisionTable(), ErrorCorrelationMgr.readFromReportFile(), AsciiNeutronReader.readNextEvent(), trklet::TripletEngine.readTables(), trklet::TrackletEngineDisplaced.readTables(), SiPixelEDAClient.SiPixelEDAClient(), TPNCor.TPNCor(), TrackerGeometryCompare.TrackerGeometryCompare(), and TrackingAnalyser.TrackingAnalyser().
Definition at line 162 of file groupFilesInBlocks.py.
Referenced by SiStripDetVOffPrinter.analyze(), BeamSpotRcdPrinter.analyze(), FastSiPixelFEDChannelContainerFromQuality.analyze(), trklet::TrackletCalculatorBase.barrelSeeding(), CMSG4CheckOverlap.CMSG4CheckOverlap(), compileDMRTrends(), trklet::TrackletCalculatorDisplaced.DDLSeeding(), trklet::TrackletCalculatorBase.diskSeeding(), PrintGeomInfoAction.dumpInFile(), DTTrigGeom.dumpLUT(), DTConfigManager.dumpLUTParam(), RunManagerMTWorker.DumpMagneticField(), EcalTPGLinearizationConstXMLTranslator.dumpXML(), trklet::MatchEngine.execute(), trklet::TripletEngine.execute(), trklet::PurgeDuplicate.execute(), trklet::TrackletEngineDisplaced.execute(), trklet::FitTrack.execute(), HIPplots.extractAlignableChiSquare(), HIPplots.extractAlignParams(), HIPplots.extractAlignShifts(), HIPplots.extractSurveyResiduals(), popcon::EcalSRPHandler.getNewObjects(), trklet::TrackletCalculatorDisplaced.LLDSeeding(), trklet::TrackletCalculatorDisplaced.LLLSeeding(), FittedEntriesManager.MakeHistos(), trklet::TrackletCalculatorBase.overlapSeeding(), EcalTPGTowerStatusXMLTranslator.plot(), EcalDCSTowerStatusXMLTranslator.plot(), EcalDAQTowerStatusXMLTranslator.plot(), ZeeCalibration.printStatistics(), popcon::EcalPedestalsHandler.readPedestalMC(), popcon::EcalPedestalsHandler.readPedestalTimestamp(), popcon::EcalPedestalsHandler.readPedestalTree(), CMSG4RegionReporter.ReportRegions(), TestHistoMgr.save(), cond::persistency::Logger.saveOnFile(), JME::JetResolutionObject.saveToFile(), and trklet::TripletEngine.writeTables().
string groupFilesInBlocks.help = "debug verbosity level" |
Definition at line 30 of file groupFilesInBlocks.py.
list groupFilesInBlocks.INFILE = sys.argv[2] |
Definition at line 41 of file groupFilesInBlocks.py.
list groupFilesInBlocks.jobsBlocks = [] |
Definition at line 141 of file groupFilesInBlocks.py.
tuple groupFilesInBlocks.lines = fin.readlines() |
Definition at line 95 of file groupFilesInBlocks.py.
Referenced by HcalChannelIterator.addListFromLmapAscii(), FWMuonDetailView.addSceneInfo(), RivetAnalyzer.beginRun(), HTXSRivetProducer.beginRun(), FWTrackResidualDetailView.build(), FWConversionProxyBuilder.buildViewType(), templateHelper::SiPixelTitles_Display< PayloadType, StoreType, TransientType >.fill(), DTTFFEDSim.fillRawData(), GenWeightsTableProducer.globalBeginRun(), DD4hep_ListGroups.overlayEtaReferences(), ListGroups.overlayEtaReferences(), DBoxMetadataHelper::DBMetaDataPlotDisplay.plotDiffWithMetadata(), DBoxMetadataHelper::DBMetaDataPlotDisplay.plotMetaDatas(), DTuROSRawToDigi.process(), DTTFFEDReader.process(), DTuROSDigiToRaw.process(), DD4hep_ListGroups.produceAndSaveSummaryPlot(), ListGroups.produceAndSaveSummaryPlot(), gen::Pythia6Service.Pythia6Service(), LMap::impl.read(), HcalEmap.read_map(), EMap.read_map(), DTuROSRawToDigi.readline(), L1TTwinMuxRawToDigi.readline(), and L1GtVmeWriterCore.writeVME().
tuple groupFilesInBlocks.match = comment1RE.match(line) |
Definition at line 107 of file groupFilesInBlocks.py.
tuple groupFilesInBlocks.NBLOCKS = int(sys.argv[1]) |
Definition at line 40 of file groupFilesInBlocks.py.
int groupFilesInBlocks.ntotal = 0 |
Definition at line 100 of file groupFilesInBlocks.py.
Referenced by cms::FastSimDataFilter.beginJob(), GenXSecAnalyzer.compute(), cms::FastSimDataFilter.endJob(), cms::FastSimDataFilter.filter(), lhef::LHERunInfo.statistics(), and lhef::LHERunInfo.xsec().
list groupFilesInBlocks.OUTFILE = sys.argv[3] |
Definition at line 42 of file groupFilesInBlocks.py.
tuple groupFilesInBlocks.parser = optparse.OptionParser(usage) |
To parse commandline args.
Definition at line 27 of file groupFilesInBlocks.py.
list groupFilesInBlocks.prog = sys.argv[0] |
Definition at line 16 of file groupFilesInBlocks.py.
groupFilesInBlocks.temp = eventsFiles |
Definition at line 142 of file groupFilesInBlocks.py.
Referenced by Config.Modifier._toModify(), FWEventItemsManager.add(), addAreaInfoTo(), FWItemValueGetter.addEntry(), jsoncollector::FastMonitor.addFastPathDefinition(), APVShotFinder.addShots(), FWGUIManager.addTo(), ME0SegAlgoRU.addUniqueSegments(), GE0SegAlgoRU.addUniqueSegments(), TagProbeFitter.addVariable(), edm::PrincipalCache.adjustIndexesAfterProductRegistryAddition(), algorithm(), ApvTimingAlgorithm.analyse(), SiPixelGenErrorDBObjectReader.analyze(), SiPixelGenErrorDBObjectUploader.analyze(), SiPixel2DTemplateDBObjectUploader.analyze(), SiPixelTemplateDBObjectUploader.analyze(), SiPixelTrackResidualSource.analyze(), SiStripMonitorPedestals.analyze(), HLTHiggsSubAnalysis.analyze(), SMPDQM.analyze(), egamma::conv.arbitrateConversionPartnersbyR(), L1RCTJetSummaryCard.asicCompare(), L1RCTJetSummaryCard.asicSort(), edm::ThinnedAssociationsHelper.associationToBranches(), PFEGammaAlgo.attachPSClusters(), TauDiscriminantCutMultiplexerT< TauType, TauTypeRef, ParentClass >.beginEvent(), PhysicsPerformanceDBWriterTFormula_fromfile_WPandPL.beginJob(), PhysicsPerformanceDBWriterFromFile_WPandPayload.beginJob(), PhysicsPerformanceDBWriterFromFile_WPandPayload_IOV.beginJob(), SiPixelDQMRocLevelAnalyzer.beginJob(), SiStripCommissioningOfflineClient.beginRun(), MaterialBudgetHcalProducer.beginRun(), L1GtVhdlWriterBitManager.bin2hex(), Blowfish_Decrypt(), Blowfish_Encrypt(), L1TdeCSCTPGClient.book(), phase2tkharvestutil.book1DFromPSet(), phase2tkutil.book1DFromPSet(), phase2tkharvestutil.book2DFromPSet(), phase2tkutil.book2DFromPSet(), L1TdeCSCTPG.bookHistograms(), SiStripMonitorTrack.bookLayerMEs(), SiPixelRawDataErrorSource.bookMEs(), phase2tkharvestutil.bookProfile1DFromPSet(), phase2tkutil.bookProfile1DFromPSet(), FastTimeParametersFromDD.build(), Basic2DGenericTopoClusterizer.buildClusters(), L1GtVhdlWriterBitManager.buildDeltaPhiMuon(), SiStripFedCablingBuilderFromDb.buildFecCablingFromDevices(), SiStripFedCabling.buildFedCabling(), DDG4Builder.BuildGeometry(), MTDGeomBuilderFromGeometricTimingDet.buildPixel(), TrackerGeomBuilderFromGeometricDet.buildPixel(), RunRangeDependentPedeLabeler.buildRunRangeDependencyMap(), CSCSegAlgoST.buildSegments(), CSCSegAlgoTC.buildSegments(), CSCSegAlgoDF.buildSegments(), CSCSegAlgoSK.buildSegments(), CSCSegAlgoRU.buildSegments(), TrackerGeomBuilderFromGeometricDet.buildSilicon(), CmsDetConstruction< FilteredView >.buildSmallDetsforGlued(), CmsDetConstruction< FilteredView >.buildSmallDetsforStack(), L1GctJetFinderBase.calcHfSums(), RazorVarProducer.CalcMR(), razor.CalcMR(), HLTRFilter.CalcMR(), SUSY_HLT_Razor.CalcMR(), razor.CalcMTR(), JetPlusTrackCorrector.calculateCorr(), CSCSegAlgoST.chainHits(), HcalQie.charge(), SensitiveDetectorCatalog.className(), SensitiveDetectorCatalog.classNames(), L1TMuonBarrelKalmanRegionModule.cleanHigher(), L1TMuonBarrelKalmanRegionModule.cleanLower(), L1TMuonBarrelKalmanSectorProcessor.cleanNeighbor(), L1TMuonBarrelKalmanSectorProcessor.cleanNeighbors(), TTClusterAlgorithm_official< T >.Cluster(), CSCSegAlgoPreClustering.clusterHits(), CSCSegAlgoST.clusterHits(), HcalQie.code(), SiStripEventSummary.commissioningInfo(), edm::hash_detail.compactForm_(), DCCTBEventBlock.compare(), edm::Hash< EntryDescriptionType >.compareUsing(), TIDLayer.components(), Phase2EndcapLayer.components(), RazorComputer.compute(), MuonME0SegHarvestor.ComputeEff(), MuonME0DigisHarvestor.ComputeEff(), L1GctHardwareJetFinder.convertClustersToOutputJets(), edm::ParameterSetConverter.convertParameterSets(), edm::ParameterSet.copyForModify(), MuonMETAlgo.correctMETforMuon(), edm::eventsetup.createDecoratorFrom(), TkAccumulatingSensitiveDetector.createHit(), DDI::Specific.createPartSelections(), TGeoMgrFromDdd.createShape(), edm::soa::Table< Args >::CtrFillerFromContainers.ctrFiller(), VectorHitBuilderAlgorithm.curvatureANDphi(), DDTBH4Algo.ddname(), DDEcalAPDAlgo.ddname(), DDEcalBarrelNewAlgo.ddname(), DDEcalBarrelAlgo.ddname(), DDEcalEndcapAlgo.ddname(), edm.decode(), GeometricTimingDet.deepComponents(), TT6ApvMask.defineNoisy(), edm::WaitingTask.dependentTaskFailed(), SiStripDigitizerAlgorithm.digitize(), Pythia8::PowhegHooksBB4L.doVetoProcessLevel(), EmDQMPostProcessor.dqmEndJob(), Phase1PixelMaps.drawSummaryMaps(), edm::RootFile.dropOnInputAndReorder(), CocoaDaqRootEvent.DumpIt(), eigen_solve_submatrix(), reco::PFCandidate.elementsInBlocks(), edm::EmptyESSource.EmptyESSource(), edm::GeneratorFilter< HAD, DEC >.endLuminosityBlockProduce(), edm::HadronizerFilter< HAD, DEC >.endLuminosityBlockProduce(), L1GctJetFinderBase.etComponentForJetFinder(), DCCTBEventBlock.eventErrorString(), DaqScopeModeSummaryFactory.extract(), NoiseSummaryFactory.extract(), PedestalsSummaryFactory.extract(), PedsFullNoiseSummaryFactory.extract(), PedsOnlySummaryFactory.extract(), CalibrationSummaryFactory.extract(), CommissioningHistograms.extractHistograms(), L1TMuon::DTCollector.extractPrimitives(), jsoncollector::FastMonitor.FastMonitor(), EcalCondDBInterface.fetchFEDelaysForRun(), L1GctJetFinderBase.fetchProtoJetsFromNeighbour(), SummaryGeneratorControlView.fill(), SummaryGeneratorReadoutView.fill(), reco::Vertex.fill(), MaterialBudgetHcalHistos.fillBeginJob(), SiPixelGainCalibrationReadDQMFile.fillDatabase(), HLTPixelClusterShapeFilter.fillDescriptions(), L2MuonIsolationProducer.fillDescriptions(), HLTHcalSimpleRecHitFilter.fillDescriptions(), HLTDTActivityFilter.fillDescriptions(), SiPixelActionExecutor.fillFEDErrorSummary(), MuonShowerInformationFiller.fillHitsByStation(), FWExpressionValidator.fillOptions(), edm.fillPathSummary(), SiPixelActionExecutor.fillSummary(), MTDGeometry.fillTestMap(), TrackerGeometry.fillTestMap(), reco::VertexCompositePtrCandidate.fillVertexCovariance(), egamma::conv.findBestConversionMatch(), TTCluster< T >.findCols(), L1GctHardwareJetFinder.findFinalClusters(), L1GctHardwareJetFinder.findProtoClusters(), TTCluster< T >.findRows(), DivisiveVertexFinder.findVertexesAlt(), edm::pathStatusExpression::ShuntingYardAlgorithm.finish(), BSFitter.Fit_d0phi(), edm::hash_detail.fixup_(), edm::ParameterSet.fromString(), GammaLn(), FullModelReactionDynamics.GenerateNBodyEvent(), FullModelReactionDynamics.GenerateXandPt(), DTRecoConditions.get(), edm::EventSetup.get(), fwlite::Handle< Collection >.getByLabel(), hgcal::ClusterTools.getClusterHadronFraction(), SimG4HcalHitJetFinder.getClusters(), HcalLaserEventFilter.GetCMSSWVersion(), HcalQie.getCode(), DDG4Builder.getDouble(), L1GlobalCaloTrigger.getEtHadCollection(), L1GlobalCaloTrigger.getEtMissCollection(), L1GlobalCaloTrigger.getEtSumCollection(), L1GlobalCaloTrigger.getHFBitCountsCollection(), L1GlobalCaloTrigger.getHFRingEtSumsCollection(), HBHEHitMapOrganizer.getHPDNeighbors(), L1GlobalCaloTrigger.getHtMissCollection(), MuonGeometryNumbering.getInt(), DDG4Builder.getInt(), DCCEETCCBlock.getLength(), edm::OneLumiPoolSource.getNextItemType(), CmsTrackerLevelBuilderHelper.getPhiGluedModule(), CmsTrackerLevelBuilderHelper.getPhiModule(), PhysicsPerformancePayload.getRow(), ExtractStringFromDD< FilteredView >.getString(), ExtractStringFromDDD< FilteredView >.getString(), DDG4SensitiveConverter.getString(), ApvAnalysisFactory.getStripNoise(), ApvAnalysisFactory.getStripPedestal(), ApvAnalysisFactory.getStripRawNoise(), L1GtVhdlTemplateFile.getSubstitutionParametersFromTemplate(), GenXSecAnalyzer.globalEndRun(), HcalDDDRecConstants.HcalCellTypes(), HCalSD.HCalSD(), L1GtVhdlWriterBitManager.hex2bin(), HGCalRecHitValidation.HGCalRecHitValidation(), HGCDigitizer.HGCDigitizer(), HGCFEElectronics< DFr >.HGCFEElectronics(), edm::RangeMap< det_id_type, edm::OwnVector< B > >.ids(), GSFTrackImporter.importToBlock(), edm::IndexIntoFile::IndexIntoFileItr.IndexIntoFileItr(), dqmservices::TriggerSelector.init(), SiStripDetKey.initFromPath(), SiStripFecKey.initFromPath(), SiStripFedKey.initFromPath(), DDAngular.initialize(), PerformancePayloadFromBinnedTFormula.initialize(), PerformancePayloadFromTFormula.initialize(), L1GtVhdlTemplateFile.insert(), ApvAnalysisFactory.instantiateApvs(), reco::helper::VirtualJetProducerHelper.intersection(), MTDTransientTrackingRecHit.isBTL(), MTDTransientTrackingRecHit.isETL(), CmsTrackerDetIdBuilder.iterate(), PixelRegions.itoa(), edm::eventsetup::DataProxyProvider.keyedProxies(), L1GtVhdlWriterCore.L1GtVhdlWriterCore(), L1MuBMTrackFinder.L1MuBMTrackFinder(), L1MuDTTrackFinder.L1MuDTTrackFinder(), L1MuGlobalMuonTrigger.L1MuGlobalMuonTrigger(), DTPattern.latHitIn(), HcalTestAnalysis.layerGrouping(), PFEGammaAlgo.linkRefinableObjectPrimaryGSFTrackToECAL(), PFEGammaAlgo.linkRefinableObjectPrimaryGSFTrackToHCAL(), edm::storage::LocalCacheFile.LocalCacheFile(), SensitiveDetectorCatalog.logicalNamesFromClassName(), HadronicProcessHelper.m_readAndParse(), HybridClusterAlgo.mainSearch(), HGCal3DClustering.makeClusters(), align.makeNonOverlappingRunRanges(), HGCalDepthPreClusterer.makePreClusters(), L1GctHardwareJetFinder.makeProtoJet(), HFShower.makeSteps(), HDShower.makeSteps(), SignCaloSpecificAlgo.makeVectorOutOfCaloTowers(), jpt::Map.Map(), edm::MergeableRunProductMetadata.mergeLumisFromIndexIntoFile(), L1GtVhdlWriterBitManager.mirror(), mat4.MulVec(), L1CaloEcalScaleConfigOnlineProd.newObject(), edm::storage::GsiFTPStorageMaker.open(), edm::storage::HttpStorageMaker.open(), TkClonerImpl.operator()(), edm::es::Label.operator()(), VersionedSelector< T >.operator()(), L1GctJetCount< nBits >.operator+(), L1GctUnsignedInt< nBits >.operator+(), L1GctTwosComplement< nBits >.operator+(), L1GctJetFinderBase::hfTowerSumsType.operator+(), L1GctJetCount< nBits >.operator++(), Json::ValueConstIterator.operator++(), Json::ValueIterator.operator++(), L1GctTwosComplement< nBits >.operator-(), Json::ValueConstIterator.operator--(), Json::ValueIterator.operator--(), operator<<(), edm::reftobase::Holder< T, REF >.operator=(), edm::reftobase::RefVectorHolder< REFV >.operator=(), edm::reftobase::IndirectVectorHolder< T >.operator=(), edm::EDCollection< T >.operator=(), L1GctHfBitCountsLut.operator=(), edm::reftobase::IndirectHolder< T >.operator=(), edm::CloningPtr< T, P >.operator=(), L1GctHtMissLut.operator=(), FWConfiguration.operator=(), CastorElectronicsMap.operator=(), edm::HepMCProduct.operator=(), edm::RefVectorBase< key_type >.operator=(), edm::RefToBaseVector< T >.operator=(), edm::eventsetup::DataKey.operator=(), edm::reftobase::VectorHolder< T, REFVECTOR >.operator=(), edm::OrphanHandleBase.operator=(), CrossingFrame< T >.operator=(), HcalFrontEndMap.operator=(), edm::ErrorObj.operator=(), L1GctHfEtSumsLut.operator=(), fwlite::Handle< Collection >.operator=(), HcalDcsMap.operator=(), edm::ESGetToken< L1TriggerKeyList, L1CaloEcalScaleRcd >.operator=(), HcalSiPMCharacteristics.operator=(), HcalElectronicsMap.operator=(), edm::HandleBase.operator=(), edm::TriggerResults.operator=(), edm::TriggerNames.operator=(), edm::Association< C >.operator=(), edm::FileInPath.operator=(), edm::DataFrameContainer.operator=(), edm::HLTGlobalStatus.operator=(), edm::value_ptr< edm::service::MessageLoggerDefaults >.operator=(), edm::RefToBaseProd< T >.operator=(), edm::Handle< GenericObject >.operator=(), edm::EDGetTokenT< FEDRawDataCollection >.operator=(), cms::Exception.operator=(), edm::Handle< FWGenericObject >.operator=(), edm::EDPutTokenT< FEDRawDataCollection >.operator=(), edm::Exception.operator=(), edm::SortedCollection< T, SORT >.operator=(), edm::ValueMap< math::XYZTLorentzVector >.operator=(), edm::MapOfVectors< std::string, AnalysisDescription * >.operator=(), edm::SoATuple< edm::EDConsumerBase::TokenLookupInfo, bool, edm::EDConsumerBase::LabelPlacement, edm::KindOfType >.operator=(), edm::DetSetRefVector< T, C >.operator=(), edm::OwnVector< T, P >.operator=(), edm::PtrVector< reco::reco::CaloCluster >.operator=(), edm::RangeMap< ID, C, P >.operator=(), edm::IDVectorMap< ID, C, P >.operator=(), l1extra::L1ParticleMap.operator=(), FastTimerService.postBeginJob(), CSCChamberTimeCorrectionsValues.prefill(), ClhepEvaluator.prepare(), edm::hash_detail.print_(), SiStripConfigDb.printAnalysisDescriptions(), SiStripConfigDb.printDeviceDescriptions(), SiStripConfigDb.printFedConnections(), SiStripConfigDb.printFedDescriptions(), L1GctElectronFinalSort.process(), TTClusterBuilder< T >.produce(), SETPatternRecognition.produce(), Phase2TrackerCablingESProducer.produce(), SiPixelFakeTemplateDBObjectESSource.produce(), SiPixelFakeGenErrorDBObjectESSource.produce(), CastorFastClusterProducer.produce(), SiStripFedCablingESProducer.produce(), MultiClustersFromTrackstersProducer.produce(), RecoTauGenericJetRegionProducer< JetType, CandType >.produce(), CastorClusterProducer.produce(), ConvBremSeedProducer.produce(), CSCTriggerPrimitivesProducer.produce(), BoostedDoubleSVProducer.produce(), reco::modules::CosmicTrackSplitter.produce(), mkfit.propagateHelixToRMPlex(), mkfit.propagateHelixToZMPlex(), CSCSegAlgoST.prune_bad_hits(), SiPixelGenError.pushfile(), SiPixelTemplate2D.pushfile(), SiPixelTemplate.pushfile(), PreMixingSiStripWorker.put(), MEtoEDM< T >.putMEtoEdmObject(), G4ProcessHelper.ReadAndParse(), StoreEcalCondition.readEcalTBWeightsFromFile(), StoreEcalCondition.readEcalWeightXtalGroupsFromFile(), popcon::RPCEMapSourceHandler.readEMap1(), DQMRootSource.readFile_(), CSCTFPtLUT.readLUT(), CSCSectorReceiverLUT.readLUTsFromFile(), SensitiveDetectorCatalog.readoutNames(), edm::ProductProvenanceRetriever.readProvenance(), edm::MergeableRunProductMetadata.readRun(), fwlite::Record.Record(), edm::ESProxyFactoryProducer.registerFactory(), edm::ESProxyFactoryProducer.registerFactoryWithKey(), FWEvePtr< T >.reset(), edm::Worker.resetModuleDescription(), L1GctGlobalHfSumAlgos.resetPipelines(), edm::soa::Table< edm::soa::col::Pt, edm::soa::col::Eta, edm::soa::col::Phi, edm::soa::col::Vz >.resetStartingAt(), BtoCharmDecayVertexMergerT< VTX >.resolveBtoDchain(), SiPixelDQMRocLevelAnalyzer.RocSumOneModule(), FullModelReactionDynamics.Rotate(), EcalClusterToolsT< noZS >.roundnessBarrelSuperClusters(), EcalClusterToolsT< noZS >.roundnessSelectedBarrelRecHits(), SiStripConfigDb.runs(), DAFTrackProducerAlgorithm.runWithCandidate(), CSCSegAlgoTC.segmentSort(), FWModelExpressionSelector.select(), L1TMuonBarrelKalmanRegionModule.selfClean(), heppy::Davismt2.set_momenta(), DCUCapsuleTempDat.setCapsuleTemp(), DCUCCSDat.setCCSTempHigh(), DCUCCSDat.setCCSTempLow(), edm::eventsetup::Callback< T, TReturn, TRecord, TDecorator >.setData(), PltSD.setDetUnitId(), L1GctMet.setExComponent(), FWModelFilter.setExpression(), FWExpressionEvaluator.setExpression(), L1GctMet.setEyComponent(), edm::service::ELdestination.setLineLength(), DCUCCSDat.setM1DCUTemp(), DCUCCSDat.setM1Vcc(), DCUCCSDat.setM1VDD1(), DCUCCSDat.setM1VDD2(), DCUCCSDat.setM1Vinj(), DCUCCSDat.setM2DCUTemp(), DCUCCSDat.setM2Vcc(), DCUCCSDat.setM2VDD1(), DCUCCSDat.setM2VDD2(), DCUCCSDat.setM2Vinj(), DCUIDarkPedDat.setPed(), DDG4ProductionCuts.setProdCuts(), gen::Pythia6Service.setPYUPDAParams(), L1GlobalCaloTrigger.setRegion(), RPCSimSetUp.setRPCSetUp(), gen::Pythia6Service.setSLHAParams(), DCULVRBTempsDat.setT1(), DCULVRTempsDat.setT1(), DCULVRTempsDat.setT2(), DCULVRBTempsDat.setT2(), DCULVRTempsDat.setT3(), DCULVRBTempsDat.setT3(), DCSPTMTemp.setTemperature(), L1GctJet.setupJet(), FWPFTrackUtils.setupLegoTrack(), TFWLiteSelectorBasic.setupNewFile(), L1GctElectronSorter.setupObjects(), DCUVFETempDat.setVFETemp(), CSCSegAlgoShowering.showerSeg(), MahiFit.solveSubmatrix(), CmsTrackerOTLayerBuilder< FilteredView >.sortNS(), CmsTrackerLayerBuilder< FilteredView >.sortNS(), CmsTrackerWheelBuilder< FilteredView >.sortNS(), CmsTrackerDiskBuilder< FilteredView >.sortNS(), CmsTrackerPhase1DiskBuilder< FilteredView >.sortNS(), CmsTrackerPixelPhase2SubDiskBuilder< FilteredView >.sortNS(), CmsTrackerPhase2TPDiskBuilder< FilteredView >.sortNS(), CmsTrackerRingBuilder< FilteredView >.sortNS(), CmsTrackerPixelPhase2DiskBuilder< FilteredView >.sortNS(), CmsTrackerOTDiscBuilder< FilteredView >.sortNS(), CmsTrackerBuilder< FilteredView >.sortNS(), L1GtVhdlTemplateFile.split(), L1MuGMTLUT::PortDecoder.str(), edm::ConcurrentGeneratorFilter< HAD, DEC >.streamEndLuminosityBlockSummary(), edm::ConcurrentHadronizerFilter< HAD, DEC >.streamEndLuminosityBlockSummary(), SourceCardRouting.STRINGtoVHDCI(), edm::ErrorObj.swap(), fwlite::Handle< Collection >.swap(), fwlite::Record.syncTo(), TracktoRPC.thePoints(), TkAccumulatingSensitiveDetector.TkAccumulatingSensitiveDetector(), edm.tns(), edm::hash_detail.toDigest_(), edm::hash_detail.toString_(), TkCommonMode.toVector(), HcalTestAnalysis.towersToAdd(), dqmservices::TriggerSelector::TreeElement.TreeElement(), sistrip::RawToDigiUnpacker.triggerFed(), edm::EventSetup.tryToGet(), FullModelReactionDynamics.TwoCluster(), DCCMemBlock.unpackMemTowerData(), DaqScopeModeHistosUsingDb.update(), PedestalsHistosUsingDb.update(), PedsFullNoiseHistosUsingDb.update(), DynamicTruncation.update(), popcon::EcalDCSHandler.updateHV(), popcon::EcalDCSHandler.updateLV(), DynamicTruncation.updateWithCSChits(), DynamicTruncation.updateWithDThits(), metsig::SignPFSpecificAlgo.useOriginalPtrs(), SiStripConfigDb.usingDatabaseCache(), edm::eventsetup::EventSetupRecordImpl.validityInterval(), vector_AND(), SourceCardRouting.VHDCItoSTRING(), edm::VParameterSetEntry.VParameterSetEntry(), HcalQie.weight(), l1t::stage2::BMTFPackerInputs.wordPhMaker(), l1t::stage2::BMTFPackerInputs.wordThMaker(), ProvenanceDumper.work_(), and edm::Wrapper< T >.Wrapper().
int groupFilesInBlocks.tt = 0 |
Definition at line 144 of file groupFilesInBlocks.py.
Referenced by BPHKinematicFit.addParticles(), DCCEETCCBlock.addTriggerPrimitivesToCollection(), ElectronCalibrationUniv.analyze(), HLTGetDigi.analyze(), SiPixelPhase1Analyzer.analyze(), TrackerRemapper.analyze(), PrimaryVertexValidation.analyze(), pat::helper::VertexingHelper.associate(), DCCTBDataMapper.buildTCCFields(), EMShower.compute(), EgammaTowerIsolationNew< NC >.compute(), TGeoMgrFromDdd.createShape(), EcalCommon.crystalToTriggerTower(), EcalSelectiveReadoutValidation.dccCh(), TowerBlockFormatter.DigiToRaw(), DataCertificationJetMET.dqmEndJob(), DAClusterizerInZ.dump(), EcalTPGStripStatusXMLTranslator.dumpXML(), spr.energyECAL(), PFEnergyCalibration.energyEmHad(), JanAlignmentAlgorithm.feed(), EcalElectronicsMapper.fillMaps(), NtupleManager.FillMeasurements(), RunDCSHVDat.fillTheMapByTime(), HIPTwoBodyDecayAnalyzer.fitDimuonVertex(), EcalLaserDbService.getLaserCorrection(), popcon::EcalDAQHandler.getNewObjects(), popcon::EcalTPGSlidingWindowHandler.getNewObjects(), popcon::EcalTPGOddWeightGroupHandler.getNewObjects(), popcon::EcalTPGWeightGroupHandler.getNewObjects(), popcon::EcalTPGFineGrainStripEEHandler.getNewObjects(), LMFRunIOV.getParameters(), LMFLmrSubIOV.getParameters(), CaloTowerGeometry.getSummary(), FastTimeGeometry.getSummary(), HGCalGeometry.getSummary(), CaloSubdetectorGeometry.getSummary(), HcalGeometry.getSummary(), LMFDefFabric.getTrigType(), LMFDefFabric.getTrigTypeFromID(), ALIFileIn.getWordsInLine(), TEcnaHistos.HistimePlot(), TEcnaHistos.HistoPlot(), EGammaMvaEleEstimator.IDIsoCombinedMvaValue(), PerformancePayloadFromBinnedTFormula.initialize(), EcalUncalibRecHitTimingCCAlgo.interpolatePulse(), GeometryInterface.loadFromTopology(), MuonTrackLoader.loadTracks(), GEMStripTopology.localError(), CSCRadialStripTopology.localError(), TkRadialStripTopology.localError(), CaloTruthCellsProducer.makeHitMap(), SiStripHistoPlotter.makePlot(), EGammaMvaEleEstimatorCSA14.mvaValue(), EGammaMvaEleEstimator.mvaValue(), TracksClusteringFromDisplacedSeed.nearTracks(), TransientVertex.operator reco::VertexCompositePtrCandidate(), TemplatedSecondaryVertexProducer< IPTI, VTX >::SVBuilder.operator()(), FWTriggerTableView.populateController(), SiPixelFedCablingMapBuilder.produce(), TrackTimeValueMapProducer.produce(), Onia2MuMuPAT.produce(), pat::PATElectronProducer.produce(), pat::PATMuonProducer.produce(), TemplatedInclusiveVertexFinder< InputContainer, VTX >.produce(), EcalDigiDisplay.readEBDigis(), EcalFEtoDigi.readInput(), MuonResiduals6DOFrphiFitter.readNtuple(), MuonResiduals5DOFFitter.readNtuple(), MuonResiduals6DOFFitter.readNtuple(), reco::GhostTrackVertexFinder.refitGhostTrack(), FWLiteESRecordWriterAnalyzer.registerLateConsumes(), FWLiteESSource.registerProxies(), btagbtvdeep.seedingTracksToFeatures(), PrimaryVertexResolution.sortTracksByPt(), TrackVertexArbitration< VTX >.trackVertexArbitrator(), DDG4SolidConverter.trunctubs(), CaloSD.update(), DAClusterizerInZ.vertices(), FEConfigFgrParamDat.writeArrayDB(), FEConfigFgrGroupDat.writeArrayDB(), FEConfigWeightGroupDat.writeArrayDB(), CaliCrystalIntercalDat.writeArrayDB(), FEConfigParamDat.writeArrayDB(), FEConfigOddWeightGroupDat.writeArrayDB(), MonPedestalsDat.writeArrayDB(), MonTTConsistencyDat.writeArrayDB(), MonTestPulseDat.writeArrayDB(), MonMemTTConsistencyDat.writeArrayDB(), MonPNLed1Dat.writeArrayDB(), MonPNIRedDat.writeArrayDB(), MonPNBlueDat.writeArrayDB(), MonPNMGPADat.writeArrayDB(), MonPNGreenDat.writeArrayDB(), MonPNLed2Dat.writeArrayDB(), MonPNRedDat.writeArrayDB(), DCULVRVoltagesDat.writeArrayDB(), and LaserSorter.writeEventHeader().
string groupFilesInBlocks.type = "int" |
Definition at line 31 of file groupFilesInBlocks.py.
Definition at line 18 of file groupFilesInBlocks.py.