CMS 3D CMS Logo

Functions | Variables
groupFilesInBlocks Namespace Reference

Functions

def makeJobBlock (mylist, evtn)
 

Variables

 args
 
 block
 
string comma = ","
 
string commandline = " "
 
string commax = ","
 
 comment1RE = re.compile(r'^#.+$')
 
list commentLines = []
 
 copyargs = sys.argv[:]
 
 default
 
 dest
 
list eventsFiles = []
 
 evtPerJob = int(math.ceil(float(ntotal)/NBLOCKS))
 
 fileLineRE = re.compile(r'^.*\'(.*)\'.+# (\d*).*$')
 
 fin = open(INFILE, "r")
 
 fout = open(OUTFILE, mode="w")
 
 help
 
 INFILE = sys.argv[2]
 
list jobsBlocks = []
 
 lines = fin.readlines()
 
 match = comment1RE.match(line)
 
 NBLOCKS = int(sys.argv[1])
 
 nn
 
int ntotal = 0
 
 options
 
 OUTFILE = sys.argv[3]
 
 parser = optparse.OptionParser(usage)
 To parse commandline args. More...
 
 prog = sys.argv[0]
 
 reverse
 
 temp = eventsFiles
 
int tt = 0
 
 type
 
string usage = './%(prog)s NBLOCKS INFILE OUTFILE [options]\n'
 

Function Documentation

def groupFilesInBlocks.makeJobBlock (   mylist,
  evtn 
)

Definition at line 46 of file groupFilesInBlocks.py.

References edm.print().

46 def makeJobBlock(mylist, evtn):
47  n = mylist[0][0]
48  block = [mylist[0]]
49  choosen = [0]
50  while n<evtn:
51  #print "n,evtn=",n,evtn
52  # find the biggest unused #evt that would give n<evtn
53  for i in range(len(mylist)):
54  # get last not choosen i
55  last_i=len(mylist)-1
56  while last_i in choosen: last_i += -1
57  if i==last_i:
58  #print i,"last element reached"
59  n += mylist[i][0]
60  #print " new last append: ",i, mylist[i][0], n
61  block.append(mylist[i])
62  choosen.append(i)
63  break
64  if i in choosen:
65  #print i," in choosen, continue..."
66  continue
67  if n+mylist[i][0]<evtn:
68  n += mylist[i][0]
69  #print " new append: ",i, mylist[i][0], n
70  block.append(mylist[i])
71  choosen.append(i)
72  break
73  if len(choosen)==len(mylist):
74  #print " got everything"
75  break
76  # pick up unused elements
77  newlist = []
78  for i in range(len(mylist)):
79  if not i in choosen:
80  newlist.append(mylist[i])
81  print("done makeJobBlock n =",n," len =",len(block))
82  return block, newlist, n
83 
84 
85 
S & print(S &os, JobReport::InputFile const &f)
Definition: JobReport.cc:66
def makeJobBlock(mylist, evtn)

Variable Documentation

groupFilesInBlocks.args

Definition at line 35 of file groupFilesInBlocks.py.

groupFilesInBlocks.block

Definition at line 150 of file groupFilesInBlocks.py.

Referenced by L1TMP7ZeroSupp.analyze(), amc::BlockHeader.BlockHeader(), PFEGammaAlgo.buildAndRefineEGObjects(), PFRecoTauAlgorithm.buildPFTau(), DTScalerInfoTask.endLuminosityBlock(), PFPhotonAlgo.EvaluateSingleLegMVA(), PFEGammaAlgo.evaluateSingleLegMVA(), l1t::MP7BufferDumpToRaw.formatAMC(), l1t::MP7BufferDumpToRaw.getBlocks(), PFEGammaAlgo.getRefinedSCs(), RBCProcessRPCDigis.initialize(), RBCProcessRPCSimDigis.initialize(), PFEGammaFilters.isElectronSafeForJetMET(), PFEGammaFilters.isPhotonSafeForJetMET(), HcalPatternSource.loadPatternFile(), ProcessTestSignal.next(), RBCProcessRPCSimDigis.next(), gen::ParameterCollector::const_iterator.next(), reco::tau::RecoTauElectronRejectionPlugin.operator()(), l1t::stage2::CaloLayer1Packer.pack(), l1t::stage2::BMTFPackerOutput.pack(), amc::Packet.Packet(), PFAlgo.processBlock(), PFBlockProducer.produce(), l1t::L1TRawToDigi.produce(), l1t::L1TDigiToRaw.produce(), SimPFProducer.produce(), amc13::Trailer.raw(), PFAlgo.reconstructParticles(), PFElectronAlgo.SetActive(), PFElectronAlgo.SetCandidates(), PFBlockAlgo.setDebug(), PFElectronAlgo.SetIDOutputs(), PFElectronAlgo.SetLinks(), gen::Pythia6Service.setSLHAFromHeader(), Herwig6Hadronizer.setSLHAFromHeader(), CSCSPRecord.unpack(), l1t::Unpacker.Unpacker(), l1t::stage2::BMTFUnpackerOutput.~BMTFUnpackerOutput(), DCCTBBlockPrototype.~DCCTBBlockPrototype(), l1t::stage2::EGammaUnpacker.~EGammaUnpacker(), l1t::stage2::EtSumUnpacker.~EtSumUnpacker(), l1t::stage2::EtSumUnpacker_0x10010057.~EtSumUnpacker_0x10010057(), l1t::stage2::IntermediateMuonUnpacker.~IntermediateMuonUnpacker(), l1t::stage2::JetUnpacker.~JetUnpacker(), l1t::stage2::MuonUnpacker.~MuonUnpacker(), and l1t::stage2::TauUnpacker.~TauUnpacker().

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.

groupFilesInBlocks.comment1RE = re.compile(r'^#.+$')

Definition at line 86 of file groupFilesInBlocks.py.

list groupFilesInBlocks.commentLines = []

Definition at line 101 of file groupFilesInBlocks.py.

groupFilesInBlocks.copyargs = sys.argv[:]

Definition at line 8 of file groupFilesInBlocks.py.

groupFilesInBlocks.default

Definition at line 32 of file groupFilesInBlocks.py.

groupFilesInBlocks.dest

Definition at line 33 of file groupFilesInBlocks.py.

list groupFilesInBlocks.eventsFiles = []

Definition at line 99 of file groupFilesInBlocks.py.

groupFilesInBlocks.evtPerJob = int(math.ceil(float(ntotal)/NBLOCKS))

Definition at line 134 of file groupFilesInBlocks.py.

groupFilesInBlocks.fileLineRE = re.compile(r'^.*\'(.*)\'.+# (\d*).*$')

Definition at line 87 of file groupFilesInBlocks.py.

groupFilesInBlocks.fin = open(INFILE, "r")
groupFilesInBlocks.fout = open(OUTFILE, mode="w")
groupFilesInBlocks.help

Definition at line 30 of file groupFilesInBlocks.py.

groupFilesInBlocks.INFILE = sys.argv[2]
list groupFilesInBlocks.jobsBlocks = []

Definition at line 141 of file groupFilesInBlocks.py.

groupFilesInBlocks.lines = fin.readlines()
groupFilesInBlocks.match = comment1RE.match(line)

Definition at line 107 of file groupFilesInBlocks.py.

groupFilesInBlocks.NBLOCKS = int(sys.argv[1])

Definition at line 40 of file groupFilesInBlocks.py.

groupFilesInBlocks.nn
int groupFilesInBlocks.ntotal = 0
groupFilesInBlocks.options

Definition at line 35 of file groupFilesInBlocks.py.

groupFilesInBlocks.OUTFILE = sys.argv[3]

Definition at line 42 of file groupFilesInBlocks.py.

groupFilesInBlocks.parser = optparse.OptionParser(usage)

To parse commandline args.

Definition at line 27 of file groupFilesInBlocks.py.

groupFilesInBlocks.prog = sys.argv[0]

Definition at line 16 of file groupFilesInBlocks.py.

groupFilesInBlocks.reverse

Definition at line 131 of file groupFilesInBlocks.py.

Referenced by DTMeantimerPatternReco.addHits(), TTUTrackingAlg.alignTracks(), L1RCTTestAnalyzer.analyze(), SegmentToTrackAssociator.associate(), DTTracoChip.bestCand(), SiStripBaseCondObjDQM.bookSummaryProfileMEs(), GlobalTrajectoryBuilderBase.build(), CSCSegAlgoTC.buildSegments(), CSCSegAlgoSK.buildSegments(), CSCSegAlgoDF.buildSegments(), CSCSegAlgoRU.buildSegments(), DirectMuonNavigation.compatibleEndcapLayers(), DirectMTDNavigation.compatibleEndcapLayers(), DirectMuonNavigation.compatibleLayers(), DirectMTDNavigation.compatibleLayers(), DirectTrackerNavigation.compatibleLayers(), MuonForwardNavigableLayer.compatibleLayers(), ETLNavigableLayer.compatibleLayers(), BTLNavigableLayer.compatibleLayers(), MuonBarrelNavigableLayer.compatibleLayers(), APVShot.computeShot(), MuonAlignment.doMatching(), CosmicMuonTrajectoryBuilder.estimateDirection(), StandAloneMuonFilter.findBestMeasurements(), CosmicMuonTrajectoryBuilder.flipTrajectory(), TrackTransformerForCosmicMuons.getTransientRecHits(), JetPartonMatching.matchingPtOrderedMinDist(), TrackMerger.merge(), MuonForwardNavigableLayer.nextLayers(), ETLNavigableLayer.nextLayers(), BTLNavigableLayer.nextLayers(), MuonBarrelNavigableLayer.nextLayers(), edm::SubProcess.processAsync(), edm::EventProcessor.processEventAsyncImpl(), edm::GlobalSchedule.processOneGlobalAsync(), TrackExtenderWithMTDT< TrackCollection >.produce(), reco::modules::TrackerTrackHitFilter.produceFromTrajectory(), DualTrajectoryFactory.referenceStateAndRecHits(), DualBzeroTrajectoryFactory.referenceStateAndRecHits(), edm::OwnVector< reco::reco::PFBlockElement >.reverse(), Trajectory.reverse(), NuclearInteractionFinder.run(), CRackTrajectoryBuilder.run(), GlobalMuonRefitter.selectMuonHits(), FWExpressionValidator.setType(), CSCSegAlgoShowering.showerSeg(), StandAloneMuonRefitter.singleRefit(), EmbeddingHepMCFilter.sort_by_convention(), GlobalCosmicMuonTrajectoryBuilder.sortHits(), CosmicMuonSmoother.sortHitsAlongMom(), MTDDetLayerGeometry.sortLayers(), MuonDetLayerGeometry.sortLayers(), CosmicMuonTrajectoryBuilder.trajectories(), GlobalCosmicMuonTrajectoryBuilder.trajectories(), TrackTransformerForCosmicMuons.transform(), TrackTransformer.transform(), and GlobalMuonRefitter.transform().

groupFilesInBlocks.temp = eventsFiles

Definition at line 142 of file groupFilesInBlocks.py.

Referenced by Config.Modifier._toModify(), FWEventItemsManager.add(), addAreaInfoTo(), FWItemValueGetter.addEntry(), APVShotFinder.addShots(), FWGUIManager.addTo(), ME0SegAlgoRU.addUniqueSegments(), TagProbeFitter.addVariable(), edm::PrincipalCache.adjustIndexesAfterProductRegistryAddition(), algorithm(), ApvTimingAlgorithm.analyse(), SiPixelTrackResidualSource.analyze(), SiStripMonitorPedestals.analyze(), HLTHiggsSubAnalysis.analyze(), egammaTools.arbitrateConversionPartnersbyR(), L1RCTJetSummaryCard.asicCompare(), L1RCTJetSummaryCard.asicSort(), edm::ThinnedAssociationsHelper.associationToBranches(), PFEGammaAlgo.attachPSClusters(), RecoTauDiscriminantCutMultiplexer.beginEvent(), PATTauDiscriminantCutMultiplexer.beginEvent(), PhysicsPerformanceDBWriterTFormula_fromfile_WPandPL.beginJob(), PhysicsPerformanceDBWriterFromFile_WPandPayload.beginJob(), PhysicsPerformanceDBWriterFromFile_WPandPayload_IOV.beginJob(), DQMSourceExample.beginJob(), SiPixelDQMRocLevelAnalyzer.beginJob(), SiStripCommissioningOfflineClient.beginRun(), L1GtVhdlWriterBitManager.bin2hex(), Blowfish_Decrypt(), Blowfish_Encrypt(), GEMHitsValidation.bookHistograms(), SiStripMonitorTrack.bookLayerMEs(), SiPixelRawDataErrorSource.bookMEs(), FastTimeParametersFromDD.build(), Basic2DGenericTopoClusterizer.buildClusters(), L1GtVhdlWriterBitManager.buildDeltaPhiMuon(), SiStripFedCablingBuilderFromDb.buildFecCablingFromDevices(), SiStripFedCabling.buildFedCabling(), DDG4Builder.BuildGeometry(), TrackerGeomBuilderFromGeometricDet.buildPixel(), MTDGeomBuilderFromGeometricTimingDet.buildPixel(), RunRangeDependentPedeLabeler.buildRunRangeDependencyMap(), CSCSegAlgoST.buildSegments(), CSCSegAlgoTC.buildSegments(), CSCSegAlgoSK.buildSegments(), CSCSegAlgoDF.buildSegments(), CSCSegAlgoRU.buildSegments(), TrackerGeomBuilderFromGeometricDet.buildSilicon(), CmsDetConstruction.buildSmallDetsforGlued(), CmsDetConstruction.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(), TTClusterAlgorithm_official< T >.Cluster(), CSCSegAlgoPreClustering.clusterHits(), CSCSegAlgoST.clusterHits(), HcalQie.code(), SiStripEventSummary.commissioningInfo(), edm::hash_detail.compactForm_(), DCCTBEventBlock.compare(), edm::Hash< EntryDescriptionType >.compareUsing(), Phase2EndcapLayer.components(), TIDLayer.components(), RazorComputer.compute(), MuonME0SegHarvestor.ComputeEff(), MuonGEMRecHitsHarvestor.ComputeEff(), MuonME0DigisHarvestor.ComputeEff(), MuonGEMDigisHarvestor.ComputeEff(), L1GctHardwareJetFinder.convertClustersToOutputJets(), edm::ParameterSetConverter.convertParameterSets(), edm::ParameterSet.copyForModify(), MuonMETAlgo.correctMETforMuon(), AttachSD.create(), edm::eventsetup.createDecoratorFrom(), TkAccumulatingSensitiveDetector.createHit(), DDI::Specific.createPartSelections(), TGeoMgrFromDdd.createShape(), TGeoFromDddService.createShape(), edm::soa::Table< Args >::CtrFillerFromContainers.ctrFiller(), DDTBH4Algo.ddname(), DDEcalAPDAlgo.ddname(), DDEcalBarrelAlgo.ddname(), DDEcalBarrelNewAlgo.ddname(), DDEcalEndcapAlgo.ddname(), edm.decode(), GeometricTimingDet.deepComponents(), TT6ApvMask.defineNoisy(), edm::WaitingTask.dependentTaskFailed(), edm::DetSetVector< T >.DetSetVector(), SiStripDigitizerAlgorithm.digitize(), Pythia8::PowhegHooksBB4L.doVetoProcessLevel(), EmDQMPostProcessor.dqmEndJob(), edm::RootFile.dropOnInput(), CocoaDaqRootEvent.DumpIt(), eigen_solve_submatrix(), reco::PFCandidate.elementsInBlocks(), edm::EmptyESSource.EmptyESSource(), HOCalibAnalyzer.endJob(), edm::GeneratorFilter< HAD, DEC >.endLuminosityBlockProduce(), edm::HadronizerFilter< HAD, DEC >.endLuminosityBlockProduce(), GenXSecAnalyzer.endRun(), L1GctJetFinderBase.etComponentForJetFinder(), DCCTBEventBlock.eventErrorString(), DaqScopeModeSummaryFactory.extract(), CalibrationSummaryFactory.extract(), NoiseSummaryFactory.extract(), PedestalsSummaryFactory.extract(), PedsFullNoiseSummaryFactory.extract(), PedsOnlySummaryFactory.extract(), CommissioningHistograms.extractHistograms(), L1TMuon::DTCollector.extractPrimitives(), FastTimerSD.FastTimerSD(), EcalCondDBInterface.fetchFEDelaysForRun(), L1GctJetFinderBase.fetchProtoJetsFromNeighbour(), SummaryGeneratorControlView.fill(), SummaryGeneratorReadoutView.fill(), reco::Vertex.fill(), MaterialBudgetHcalHistos.fillBeginJob(), HLTPixelClusterShapeFilter.fillDescriptions(), L2MuonIsolationProducer.fillDescriptions(), HLTHcalSimpleRecHitFilter.fillDescriptions(), HLTHcalCalibTypeFilter.fillDescriptions(), HLTDTActivityFilter.fillDescriptions(), SiPixelActionExecutor.fillFEDErrorSummary(), MuonShowerInformationFiller.fillHitsByStation(), FWExpressionValidator.fillOptions(), edm.fillPathSummary(), SiPixelActionExecutor.fillSummary(), MTDGeometry.fillTestMap(), TrackerGeometry.fillTestMap(), reco::VertexCompositePtrCandidate.fillVertexCovariance(), egammaTools.findBestConversionMatch(), TTCluster< T >.findCols(), L1GctHardwareJetFinder.findFinalClusters(), L1GctHardwareJetFinder.findProtoClusters(), TTCluster< T >.findRows(), FullModelReactionDynamics.FindTimeDelay(), TTTrackAssociationMap< T >.findTrackingParticlePtr(), TTClusterAssociationMap< T >.findTrackingParticlePtr(), 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(), egammaTools.getConversionInfo(), DDG4Builder.getDouble(), L1GlobalCaloTrigger.getEtHadCollection(), L1GlobalCaloTrigger.getEtMissCollection(), L1GlobalCaloTrigger.getEtSumCollection(), hgcal::ClusterTools.getEvent(), L1GlobalCaloTrigger.getHFBitCountsCollection(), L1GlobalCaloTrigger.getHFRingEtSumsCollection(), HBHEHitMapOrganizer.getHPDNeighbors(), L1GlobalCaloTrigger.getHtMissCollection(), XMLProcessor.getInstance(), DDG4Builder.getInt(), MuonDDDNumbering.getInt(), DCCEETCCBlock.getLength(), edm::OneLumiPoolSource.getNextItemType(), CmsTrackerLevelBuilder.getPhiGluedModule(), CmsMTDLevelBuilder.getPhiGluedModule(), CmsTrackerLevelBuilder.getPhiModule(), CmsMTDLevelBuilder.getPhiModule(), PhysicsPerformancePayload.getRow(), DDG4SensitiveConverter.getString(), ApvAnalysisFactory.getStripNoise(), ApvAnalysisFactory.getStripPedestal(), ApvAnalysisFactory.getStripRawNoise(), L1GtVhdlTemplateFile.getSubstitutionParametersFromTemplate(), DCSPTMTemp.getTable(), HcalDDDRecConstants.HcalCellTypes(), HCalSD.HCalSD(), L1GtVhdlWriterBitManager.hex2bin(), HGCalDigiValidation.HGCalDigiValidation(), 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(), PerformancePayloadFromBinnedTFormula.initialize(), PerformancePayloadFromTFormula.initialize(), DDAngular.initialize(), L1GtVhdlTemplateFile.insert(), ApvAnalysisFactory.instantiateApvs(), reco::helper::VirtualJetProducerHelper.intersection(), MTDTransientTrackingRecHit.isBTL(), MTDTransientTrackingRecHit.isETL(), CmsMTDDetIdBuilder.iterate(), CmsTrackerDetIdBuilder.iterate(), itoa(), edm::eventsetup::DataProxyProvider.keyedProxies(), L1GtVhdlWriterCore.L1GtVhdlWriterCore(), HcalTestAnalysis.layerGrouping(), PFEGammaAlgo.linkRefinableObjectPrimaryGSFTrackToECAL(), PFEGammaAlgo.linkRefinableObjectPrimaryGSFTrackToHCAL(), 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(), tensorflow::TBBSession.MaybeInitializeExecutionState(), tensorflow::NTSession.MaybeInitializeExecutionState(), edm::MergeableRunProductMetadata.mergeLumisFromIndexIntoFile(), L1GtVhdlWriterBitManager.mirror(), MtdSD.MtdSD(), L1CaloEcalScaleConfigOnlineProd.newObject(), SequentialCombinationGenerator< T >.next_combination(), GsiFTPStorageMaker.open(), HttpStorageMaker.open(), MakePtrFromCollection< reco::MuonCollection >.operator()(), MakeVersionedSelector< reco::Muon >.operator()(), TkClonerImpl.operator()(), edm::es::Label.operator()(), VersionedSelector< edm::Ptr< reco::Photon > >.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=(), edm::reftobase::IndirectHolder< T >.operator=(), L1GctHfBitCountsLut.operator=(), edm::CloningPtr< T, P >.operator=(), CastorElectronicsMap.operator=(), edm::RefToBaseVector< T >.operator=(), edm::RefVectorBase< key_type >.operator=(), L1GctHtMissLut.operator=(), FWConfiguration.operator=(), edm::HepMCProduct.operator=(), edm::eventsetup::DataKey.operator=(), edm::reftobase::VectorHolder< T, REFV >.operator=(), HcalFrontEndMap.operator=(), CrossingFrame< T >.operator=(), L1GctHfEtSumsLut.operator=(), edm::ErrorObj.operator=(), edm::OrphanHandleBase.operator=(), fwlite::Handle< Collection >.operator=(), HcalSiPMCharacteristics.operator=(), HcalDcsMap.operator=(), HcalElectronicsMap.operator=(), edm::HandleBase.operator=(), edm::Association< C >.operator=(), edm::TriggerResults.operator=(), edm::DataFrameContainer.operator=(), edm::FileInPath.operator=(), edm::HLTGlobalStatus.operator=(), edm::value_ptr< edm::service::MessageLoggerDefaults >.operator=(), edm::Handle< GenericObject >.operator=(), edm::RefToBaseProd< T >.operator=(), cms::Exception.operator=(), edm::Exception.operator=(), edm::Handle< FWGenericObject >.operator=(), edm::SortedCollection< T, SORT >.operator=(), edm::OwnArray< T, MAX_SIZE, P >.operator=(), edm::ValueMap< math::XYZTLorentzVector >.operator=(), edm::OwnVector< T, P >.operator=(), edm::SoATuple< edm::EDConsumerBase::TokenLookupInfo, bool, edm::EDConsumerBase::LabelPlacement, edm::KindOfType >.operator=(), edm::MapOfVectors< std::string, AnalysisDescription * >.operator=(), edm::PtrVector< reco::reco::PFCluster >.operator=(), edm::IDVectorMap< ID, C, P >.operator=(), edm::DetSetRefVector< T, C >.operator=(), edm::RangeMap< 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(), Phase2TrackerCablingESProducer.produce(), SiPixelFakeGenErrorDBObjectESSource.produce(), SETPatternRecognition.produce(), SiPixelFakeTemplateDBObjectESSource.produce(), GsfElectronFull5x5Filler.produce(), CastorFastClusterProducer.produce(), SiStripFedCablingESProducer.produce(), RecoTauGenericJetRegionProducer< JetType, CandType >.produce(), CSCTriggerPrimitivesProducer.produce(), ConvBremSeedProducer.produce(), CastorClusterProducer.produce(), BoostedDoubleSVProducer.produce(), reco::modules::CosmicTrackSplitter.produce(), CSCSegAlgoST.prune_bad_hits(), SiPixelGenError.pushfile(), SiPixelTemplate2D.pushfile(), SiPixelTemplate.pushfile(), PreMixingSiStripWorker.put(), MEtoEDM< T >.putMEtoEdmObject(), G4ProcessHelper.ReadAndParse(), StoreEcalCondition.readEcalTBWeightsFromFile(), StoreEcalCondition.readEcalWeightXtalGroupsFromFile(), popcon::RPCEMapSourceHandler.readEMap1(), CSCTFPtLUT.readLUT(), CSCSectorReceiverLUT.readLUTsFromFile(), SensitiveDetectorCatalog.readoutNames(), edm::ProductProvenanceRetriever.readProvenance(), edm::MergeableRunProductMetadata.readRun(), fwlite::Record.Record(), edm::ESProxyFactoryProducer.registerFactory(), edm::ESProxyFactoryProducer.registerFactoryWithKey(), Tau3MuReco.removeIncorrectMuon(), FWEvePtr< T >.reset(), edm::Worker.resetModuleDescription(), L1GctGlobalHfSumAlgos.resetPipelines(), edm::soa::Table< Args >.resetStartingAt(), BtoCharmDecayVertexMergerT< VTX >.resolveBtoDchain(), SiPixelDQMRocLevelAnalyzer.RocSumOneModule(), FullModelReactionDynamics.Rotate(), EcalClusterToolsT< noZS >.roundnessBarrelSuperClusters(), EcalClusterToolsT< noZS >.roundnessSelectedBarrelRecHits(), SiStripConfigDb.runs(), Comp2RefChi2.runTest(), DAFTrackProducerAlgorithm.runWithCandidate(), edm::Schedule.Schedule(), CSCSegAlgoTC.segmentSort(), FWModelExpressionSelector.select(), heppy::Davismt2.set_momenta(), DCUCapsuleTempDat.setCapsuleTemp(), DCUCCSDat.setCCSTempHigh(), DCUCCSDat.setCCSTempLow(), edm::eventsetup::Callback< T, TReturn, TRecord, TDecorator >.setData(), PltSD.setDetUnitId(), edm::Path.setEarlyDeleteHelpers(), L1GctMet.setExComponent(), FWModelFilter.setExpression(), FWExpressionEvaluator.setExpression(), L1GctMet.setEyComponent(), reco::PFTau.setisolationGammaCands(), edm::service::ELdestination.setLineLength(), DCUCCSDat.setM1DCUTemp(), DCUCCSDat.setM1Vcc(), DCUCCSDat.setM1VDD1(), DCUCCSDat.setM1VDD2(), DCUCCSDat.setM1Vinj(), DCUCCSDat.setM2DCUTemp(), DCUCCSDat.setM2Vcc(), DCUCCSDat.setM2VDD1(), DCUCCSDat.setM2VDD2(), DCUCCSDat.setM2Vinj(), TopologyWorker.setPartList(), 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(), DQMRootSource.setupFile(), L1GctJet.setupJet(), FWPFTrackUtils.setupLegoTrack(), TFWLiteSelectorBasic.setupNewFile(), L1GctElectronSorter.setupObjects(), DCUVFETempDat.setVFETemp(), CSCSegAlgoShowering.showerSeg(), MahiFit.solveSubmatrix(), CmsTrackerRingBuilder.sortNS(), CmsMTDTrayBuilder.sortNS(), CmsTrackerOTLayerBuilder.sortNS(), CmsTrackerLayerBuilder.sortNS(), CmsTrackerWheelBuilder.sortNS(), CmsTrackerPhase2TPDiskBuilder.sortNS(), CmsTrackerOTDiscBuilder.sortNS(), CmsTrackerDiskBuilder.sortNS(), CmsTrackerPixelPhase2DiskBuilder.sortNS(), CmsTrackerPhase1DiskBuilder.sortNS(), CmsTrackerBuilder.sortNS(), L1GtVhdlTemplateFile.split(), L1MuGMTLUT::PortDecoder.str(), edm::ConcurrentHadronizerFilter< HAD, DEC >.streamEndLuminosityBlockSummary(), SourceCardRouting.STRINGtoVHDCI(), edm::ErrorObj.swap(), edm::RefVector< C, T, F >.swap(), fwlite::Handle< Collection >.swap(), fwlite::Record.syncTo(), TkAccumulatingSensitiveDetector.TkAccumulatingSensitiveDetector(), edm::hash_detail.toDigest_(), edm::hash_detail.toString_(), TkCommonMode.toVector(), HcalTestAnalysis.towersToAdd(), TracktoRPC.TracktoRPC(), dqmservices::TriggerSelector::TreeElement.TreeElement(), sistrip::RawToDigiUnpacker.triggerFed(), edm::EventSetup.tryToGet(), FullModelReactionDynamics.TwoCluster(), DCCMemBlock.unpackMemTowerData(), PedsFullNoiseHistosUsingDb.update(), DaqScopeModeHistosUsingDb.update(), PedestalsHistosUsingDb.update(), DynamicTruncation.update(), popcon::EcalDCSHandler.updateHV(), popcon::EcalDCSHandler.updateLV(), DynamicTruncation.updateWithCSChits(), DynamicTruncation.updateWithDThits(), metsig::SignPFSpecificAlgo.useOriginalPtrs(), SiStripConfigDb.usingDatabaseCache(), vector_AND(), SourceCardRouting.VHDCItoSTRING(), edm::VParameterSetEntry.VParameterSetEntry(), HcalQie.weight(), l1t::stage2::BMTFPackerInputs.wordPhMaker(), l1t::stage2::BMTFPackerInputs.wordThMaker(), ProvenanceDumper.work_(), edm::Wrapper< T >.Wrapper(), edm::RefToBase< T >.~RefToBase(), and RemoteFile.~RemoteFile().

int groupFilesInBlocks.tt = 0

Definition at line 144 of file groupFilesInBlocks.py.

Referenced by DCCEETCCBlock.addTriggerPrimitivesToCollection(), ElectronCalibrationUniv.analyze(), HLTGetDigi.analyze(), PrimaryVertexValidation.analyze(), pat::helper::VertexingHelper.associate(), BPHKinematicFit.buildParticles(), DCCTBDataMapper.buildTCCFields(), EgammaHLTElectronDetaDphiProducer.calDEtaDPhiSCTrk(), EMShower.compute(), EgammaTowerIsolationNew< NC >.compute(), TGeoMgrFromDdd.createShape(), EcalCommon.crystalToTriggerTower(), EcalSelectiveReadoutValidation.dccCh(), TowerBlockFormatter.DigiToRaw(), DataCertificationJetMET.dqmEndJob(), DAClusterizerInZ.dump(), EcalTPGStripStatusXMLTranslator.dumpXML(), spr.energyECAL(), PFEnergyCalibration.energyEmHad(), EcalElectronicsMapper.fillMaps(), NtupleManager.FillMeasurements(), RunDCSHVDat.fillTheMapByTime(), HIPTwoBodyDecayAnalyzer.fitDimuonVertex(), EcalLaserDbService.getLaserCorrection(), popcon::EcalDAQHandler.getNewObjects(), popcon::EcalTPGWeightGroupHandler.getNewObjects(), popcon::EcalTPGFineGrainStripEEHandler.getNewObjects(), popcon::EcalTPGSlidingWindowHandler.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(), GeometryInterface.loadFromTopology(), CSCRadialStripTopology.localError(), TkRadialStripTopology.localError(), SiStripHistoPlotter.makePlot(), QTestConfigurationParser.monitorElementTestsMap(), EGammaMvaEleEstimatorCSA14.mvaValue(), EGammaMvaEleEstimator.mvaValue(), TracksClusteringFromDisplacedSeed.nearTracks(), TransientVertex.operator reco::VertexCompositePtrCandidate(), TemplatedSecondaryVertexProducer< IPTI, VTX >::SVBuilder.operator()(), FWTriggerTableView.populateController(), SiPixelFedCablingMapBuilder.produce(), Onia2MuMuPAT.produce(), TrackTimeValueMapProducer.produce(), pat::PATElectronProducer.produce(), pat::PATMuonProducer.produce(), TemplatedInclusiveVertexFinder< InputContainer, VTX >.produce(), EcalDigiDisplay.readEBDigis(), EcalFEtoDigi.readInput(), MuonResiduals5DOFFitter.readNtuple(), MuonResiduals6DOFrphiFitter.readNtuple(), MuonResiduals6DOFFitter.readNtuple(), reco::GhostTrackVertexFinder.refitGhostTrack(), FWLiteESSource.registerProxies(), PrimaryVertexResolution.sortTracksByPt(), TrackVertexArbitration< VTX >.trackVertexArbitrator(), DDG4SolidConverter.trunctubs(), CaloSD.update(), FWLiteESRecordWriterAnalyzer.update(), DAClusterizerInZ.vertices(), FEConfigFgrParamDat.writeArrayDB(), FEConfigFgrGroupDat.writeArrayDB(), FEConfigWeightGroupDat.writeArrayDB(), CaliCrystalIntercalDat.writeArrayDB(), FEConfigParamDat.writeArrayDB(), MonTestPulseDat.writeArrayDB(), MonTTConsistencyDat.writeArrayDB(), MonMemTTConsistencyDat.writeArrayDB(), MonPedestalsDat.writeArrayDB(), MonPNRedDat.writeArrayDB(), MonPNLed2Dat.writeArrayDB(), MonPNBlueDat.writeArrayDB(), MonPNGreenDat.writeArrayDB(), MonPNMGPADat.writeArrayDB(), MonPNIRedDat.writeArrayDB(), MonPNLed1Dat.writeArrayDB(), DCULVRVoltagesDat.writeArrayDB(), LMFRunIOV.writeDBSql(), and LaserSorter.writeEventHeader().

groupFilesInBlocks.type

Definition at line 31 of file groupFilesInBlocks.py.

string groupFilesInBlocks.usage = './%(prog)s NBLOCKS INFILE OUTFILE [options]\n'

Definition at line 18 of file groupFilesInBlocks.py.