CMS 3D CMS Logo

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

Classes

class  BaseDataset
 
class  CMSDataset
 
class  DataFile
 
class  Dataset
 
class  DatasetBase
 
class  DatasetError
 
class  EOSDataset
 
class  IntegrityCheckError
 
class  LocalDataset
 
class  MultipleDatasets
 
class  PrivateDataset
 
class  RunRange
 

Functions

def createDataset
 
def createMyDataset
 if user == 'CMS': data = CMSDataset( dataset ) elif user == 'LOCAL': if basedir is None: basedir = os.environ['CMGLOCALBASEDIR'] data = LocalDataset( dataset, basedir, pattern ) else: data = Dataset( user, dataset, pattern ) More...
 
def dasquery
 
def findinjson
 
def getDatasetFromCache
 
def getrunnumbersfromfile
 
def writeDatasetToCache
 

Variables

string action = 'store_true'
 
tuple data
 
tuple dataset = Dataset( datasetName )
 
string datasetName = '/MinimumBias/Run2012D-TkAlMinBias-v1/ALCARECO'
 
 default = False,
 
string defaultdasinstance = "prod/global"
 
string end = "20121128"
 
string firstRun = "207800"
 
string help = 'print absolute path'
 
 info = notoptions.noinfo
 
tuple jsonFile
 
 jsonPath = jsonFile,
 
list name = args[0]
 
tuple parser = OptionParser()
 
tuple run_range = (options.min_run,options.max_run)
 
 user = options.user
 
string validationfooter
 
string validationheader
 

Function Documentation

def dataset.createDataset (   user,
  dataset,
  pattern,
  readcache = False,
  basedir = None,
  run_range = None 
)

Definition at line 429 of file dataset.py.

References getDatasetFromCache(), and writeDatasetToCache().

Referenced by datasetToSource.datasetToSource(), production_tasks.CheckDatasetExists.run(), production_tasks.SourceCFG.run(), and writeDatasetToCache().

430  basedir = None, run_range = None):
431 
432 
433  def cacheFileName(data, user, pattern):
434  return '{user}%{name}%{pattern}.pck'.format( user = user, name = data.replace('/','_'), pattern = pattern)
435 
436  def writeCache(dataset):
437  writeDatasetToCache( cacheFileName(dataset.name, dataset.user, dataset.pattern), dataset )
438 
439  def readCache(data, user, pattern):
440  return getDatasetFromCache( cacheFileName(data, user, pattern) )
441 
442  if readcache:
443  try:
444  data = readCache(dataset, user, pattern)
445  except IOError:
446  readcache = False
447  if not readcache:
448  if user == 'CMS':
449  data = CMSDataset( dataset , run_range = run_range)
450  info = False
451  elif user == 'LOCAL':
452  data = LocalDataset( dataset, basedir, pattern)
453  info = False
454  elif user == 'EOS':
455  data = EOSDataset(dataset, basedir, pattern)
456  info = False
457  else:
458  data = Dataset( dataset, user, pattern)
writeCache(data)
def writeDatasetToCache
Definition: dataset.py:421
def getDatasetFromCache
Definition: dataset.py:415
def dataset.createMyDataset (   user,
  dataset,
  pattern,
  dbsInstance,
  readcache = False 
)

if user == 'CMS': data = CMSDataset( dataset ) elif user == 'LOCAL': if basedir is None: basedir = os.environ['CMGLOCALBASEDIR'] data = LocalDataset( dataset, basedir, pattern ) else: data = Dataset( user, dataset, pattern )

MM

Definition at line 470 of file dataset.py.

References join().

Referenced by datasetToSource.myDatasetToSource().

471 def createMyDataset( user, dataset, pattern, dbsInstance, readcache=False):
472 
473  cachedir = '/'.join( [os.environ['HOME'],'.cmgdataset'])
474 
475  def cacheFileName(data, user, dbsInstance, pattern):
476  cf = data.replace('/','_')
477  name = '{dir}/{user}%{dbsInstance}%{name}%{pattern}.pck'.format(
478  dir = cachedir,
479  user = user,
480  dbsInstance = dbsInstance,
481  name = cf,
482  pattern = pattern)
483  return name
484 
485  def writeCache(dataset):
486  if not os.path.exists(cachedir):
487  os.mkdir(cachedir)
488  cachename = cacheFileName(dataset.name,
489  dataset.user,
490  dataset.dbsInstance,
491  dataset.pattern)
492  pckfile = open( cachename, 'w')
493  pickle.dump(dataset, pckfile)
494 
495  def readCache(data, user, dbsInstance, pattern):
496  cachename = cacheFileName(data, user, dbsInstance, pattern)
497 
498  pckfile = open( cachename)
499  dataset = pickle.load(pckfile)
500  #print 'reading cache'
501  return dataset
502 
503  if readcache:
504  try:
505  data = readCache(dataset, user, dbsInstance, pattern)
506  except IOError:
507  readcache = False
508  if not readcache:
509  if user == 'PRIVATE':
510  data = PrivateDataset( dataset, dbsInstance )
511  info = False
512  writeCache(data)
return data
def createMyDataset
if user == 'CMS': data = CMSDataset( dataset ) elif user == 'LOCAL': if basedir is None: basedir = os...
Definition: dataset.py:470
static std::string join(char **cmd)
Definition: RemoteFile.cc:19
def dataset.dasquery (   dasQuery,
  dasLimit = 0 
)

Definition at line 27 of file dataset.py.

References findinjson(), das_client.get_data(), and str.

Referenced by dataset.Dataset.getfiles(), and getrunnumbersfromfile().

27 
28 def dasquery(dasQuery, dasLimit=0):
29  dasData = das_client.get_data(dasQuery, dasLimit)
30  if isinstance(dasData, str):
31  jsondict = json.loads( dasData )
32  else:
33  jsondict = dasData
34  # Check, if the DAS query fails
35  try:
36  error = findinjson(jsondict, "data","error")
37  except KeyError:
38  error = None
39  if error or findinjson(jsondict, "status") != 'ok' or "data" not in jsondict:
40  try:
41  jsonstr = findinjson(jsondict, "reason")
42  except KeyError:
43  jsonstr = str(jsondict)
44  if len(jsonstr) > 10000:
45  jsonfile = "das_query_output_%i.txt"
46  i = 0
47  while os.path.lexists(jsonfile % i):
48  i += 1
49  jsonfile = jsonfile % i
50  theFile = open( jsonfile, "w" )
51  theFile.write( jsonstr )
52  theFile.close()
53  msg = "The DAS query returned an error. The output is very long, and has been stored in:\n" + jsonfile
54  else:
55  msg = "The DAS query returned a error. Here is the output\n" + jsonstr
56  msg += "\nIt's possible that this was a server error. If so, it may work if you try again later"
57  raise DatasetError(msg)
58  return findinjson(jsondict, "data")
def findinjson
Definition: dataset.py:95
def get_data
Definition: das_client.py:276
def dasquery
Definition: dataset.py:27
#define str(s)
def dataset.findinjson (   jsondict,
  strings 
)

Definition at line 95 of file dataset.py.

Referenced by dasquery(), dataset.Dataset.getfiles(), and getrunnumbersfromfile().

95 
96 def findinjson(jsondict, *strings):
97  if len(strings) == 0:
98  return jsondict
99  if isinstance(jsondict,dict):
100  if strings[0] in jsondict:
101  try:
102  return findinjson(jsondict[strings[0]], *strings[1:])
103  except KeyError:
104  pass
105  else:
106  for a in jsondict:
107  if strings[0] in a:
108  try:
109  return findinjson(a[strings[0]], *strings[1:])
110  except (TypeError, KeyError): #TypeError because a could be a string and contain strings[0]
111  pass
112  #if it's not found
113  raise KeyError("Can't find " + strings[0])
def findinjson
Definition: dataset.py:95
def dataset.getDatasetFromCache (   cachename)

Definition at line 415 of file dataset.py.

References join().

Referenced by createDataset().

416 def getDatasetFromCache( cachename ) :
417  cachedir = '/'.join( [os.environ['HOME'],'.cmgdataset'])
418  pckfile = open( cachedir + "/" + cachename )
419  dataset = pickle.load(pckfile)
420  return dataset
def getDatasetFromCache
Definition: dataset.py:415
static std::string join(char **cmd)
Definition: RemoteFile.cc:19
def dataset.getrunnumbersfromfile (   filename,
  trydas = True,
  allowunknown = False,
  dasinstance = defaultdasinstance 
)

Definition at line 59 of file dataset.py.

References python.cmstools.all(), dasquery(), findinjson(), join(), and str.

59 
60 def getrunnumbersfromfile(filename, trydas=True, allowunknown=False, dasinstance=defaultdasinstance):
61  parts = filename.split("/")
62  error = None
63  if parts[0] != "" or parts[1] != "store":
64  error = "does not start with /store"
65  elif parts[2] in ["mc", "relval"]:
66  return [1]
67  elif not parts[-1].endswith(".root"):
68  error = "does not end with something.root"
69  elif len(parts) != 12:
70  error = "should be exactly 11 slashes counting the first one"
71  else:
72  runnumberparts = parts[-5:-2]
73  if not all(len(part)==3 for part in runnumberparts):
74  error = "the 3 directories {} do not have length 3 each".format("/".join(runnumberparts))
75  try:
76  return [int("".join(runnumberparts))]
77  except ValueError:
78  error = "the 3 directories {} do not form an integer".format("/".join(runnumberparts))
79 
80  if error and trydas:
81  try:
82  query = "run file={} instance={}".format(filename, dasinstance)
83  dasoutput = dasquery(query)
84  result = findinjson(dasoutput, "run")
85  return sum((findinjson(run, "run_number") for run in result), [])
86  except Exception as e:
87  error = str(e)
88 
89  if error and allowunknown:
90  return [-1]
91 
92  if error:
93  error = "could not figure out which run number this file is from.\nMaybe try with allowunknown=True?\n {}\n{}".format(filename, error)
94  raise DatasetError(error)
def findinjson
Definition: dataset.py:95
def dasquery
Definition: dataset.py:27
def all
workaround iterator generators for ROOT classes
Definition: cmstools.py:25
static std::string join(char **cmd)
Definition: RemoteFile.cc:19
#define str(s)
def getrunnumbersfromfile
Definition: dataset.py:59
def dataset.writeDatasetToCache (   cachename,
  dataset 
)

Definition at line 421 of file dataset.py.

References createDataset(), and join().

Referenced by createDataset().

422 def writeDatasetToCache( cachename, dataset ):
423  cachedir = '/'.join( [os.environ['HOME'],'.cmgdataset'])
424  if not os.path.exists(cachedir):
425  os.mkdir(cachedir)
426  pckfile = open( cachedir + "/" + cachename, 'w')
427  pickle.dump(dataset, pckfile)
def writeDatasetToCache
Definition: dataset.py:421
static std::string join(char **cmd)
Definition: RemoteFile.cc:19

Variable Documentation

string dataset.action = 'store_true'

Definition at line 20 of file dataset.py.

tuple dataset.data
Initial value:
1 = createDataset(user, name,
2  fnmatch.translate( options.wildcard ),
3  options.readcache,
4  options.basedir,
5  run_range=run_range)
def createDataset
Definition: dataset.py:429

Definition at line 49 of file dataset.py.

tuple dataset.dataset = Dataset( datasetName )

Definition at line 934 of file dataset.py.

string dataset.datasetName = '/MinimumBias/Run2012D-TkAlMinBias-v1/ALCARECO'

Definition at line 930 of file dataset.py.

dataset.default = False,

Definition at line 21 of file dataset.py.

string dataset.defaultdasinstance = "prod/global"

Definition at line 15 of file dataset.py.

string dataset.end = "20121128"

Definition at line 937 of file dataset.py.

Referenced by LEDTask._process(), DigiTask._process(), SiStripAPVRestorer.abnormalBaselineInspect(), DDSpecificsFilter.accept_impl(), HGCDigitizer.accumulate(), HGCDigitizer.accumulate_forPreMix(), cms::Phase2TrackerDigitizer.accumulatePixelHits(), HBHERecHitProducerGPU.acquire(), edm::helper::Filler< Association< C > >.add(), MuonBaseNumber.addBase(), FWRecoGeometryESProducer.addCaloGeometry(), FWTGeoRecoGeometryESProducer.addCaloTowerGeometry(), FWRecoGeometryESProducer.addCSCGeometry(), FWRecoGeometryESProducer.addDTGeometry(), FWTGeoRecoGeometryESProducer.addDTGeometry(), FWTGeoRecoGeometryESProducer.addEcalCaloGeometry(), FWTGeoRecoGeometryESProducer.addGEMGeometry(), FWTGeoRecoGeometryESProducer.addHcalCaloGeometryBarrel(), FWTGeoRecoGeometryESProducer.addHcalCaloGeometryEndcap(), FWTGeoRecoGeometryESProducer.addHcalCaloGeometryForward(), FWTGeoRecoGeometryESProducer.addHcalCaloGeometryOuter(), ClusterTPAssociation.addKeyID(), pat::TriggerEvent.addObjectMatchResult(), reco::tau::RecoTauConstructor.addPFCands(), PreMixingSiPixelWorker.addPileups(), PreMixingSiStripWorker.addPileups(), FWRecoGeometryESProducer.addPixelBarrelGeometry(), FWRecoGeometryESProducer.addPixelForwardGeometry(), reco::tau::RecoTauConstructor.addPiZeros(), FWRecoGeometryESProducer.addRPCGeometry(), FWTGeoRecoGeometryESProducer.addRPCGeometry(), PreMixingSiPixelWorker.addSignals(), PreMixingSiStripWorker.addSignals(), GEMClusterProcessor.addSingleClusters(), edm::DataMixingSiPixelWorker.addSiPixelPileups(), edm::DataMixingSiPixelWorker.addSiPixelSignals(), edm::DataMixingSiStripWorker.addSiStripPileups(), edm::DataMixingSiStripWorker.addSiStripSignals(), reco::tau::RecoTauConstructor.addTauChargedHadrons(), FWRecoGeometryESProducer.addTECGeometry(), FWRecoGeometryESProducer.addTIBGeometry(), FWRecoGeometryESProducer.addTIDGeometry(), FWRecoGeometryESProducer.addTOBGeometry(), SiStripHitEffFromCalibTree.algoAnalyze(), SiStripGainCosmicCalculator.algoBeginJob(), pat::EventHypothesis.all(), L1TriggerKeyExtViewer.analyze(), DumpFWRecoGeometry.analyze(), L1TGlobalPrescalesVetosViewer.analyze(), SiStripDigiValid.analyze(), DD4hep_TrackingMaterialAnalyser.analyze(), TrackingMaterialAnalyser.analyze(), HiBasicGenTest.analyze(), L1CondDBIOVWriterExt.analyze(), SiPixelDigiValid.analyze(), L1CondDBPayloadWriterExt.analyze(), L1TMP7ZeroSupp.analyze(), HistoAnalyzer< C >.analyze(), L1CondDBIOVWriter.analyze(), L1CondDBPayloadWriter.analyze(), ClusterCount.analyze(), CaloParticleDebugger.analyze(), PPSPixelDigiAnalyzer.analyze(), HLTMuonMatchAndPlotContainer.analyze(), TestPythiaDecays.analyze(), SiStripFEDMonitorPlugin.analyze(), HLTObjectMonitorProtonLead.analyze(), HLTObjectMonitor.analyze(), PrimaryVertexAnalyzer4PUSlimmed.analyze(), TrackerDpgAnalysis.analyze(), HGCalTBAnalyzer.analyzeSimHits(), reco::HitPattern.appendHits(), RunInfoUpdate.appendNewRun(), edm::ProductSelectorRules.applyToAll(), edm::ProductSelectorRules::Rule.applyToAll(), pat::helper::VertexingHelper.associate(), TrackerHitAssociator.associateHit(), LCToSimTSAssociatorByEnergyScoreImpl.associateRecoToSim(), LCToSimTSAssociatorByEnergyScoreImpl.associateSimToReco(), SiStripAPVRestorer.baselineAndSaturationInspect(), SiStripAPVRestorer.baselineFollowerInspect(), trigger::TriggerEventWithRefs.basemetSlice(), l1t::OMDSReader.basicQuery(), l1t::OMDSReader.basicQueryGenericKey(), HLTMuonMatchAndPlotContainer.beginRun(), JetCorrectorParametersHelper.binIndexN(), PhysicsTools::BitSet.bits(), GctFormatTranslateV35.blockToGctInternEmCand(), GctFormatTranslateV38.blockToGctInternEmCand(), GctFormatTranslateV35.blockToRctCaloRegions(), GctFormatTranslateV38.blockToRctCaloRegions(), GctFormatTranslateV35.blockToRctEmCand(), GctFormatTranslateV38.blockToRctEmCand(), GctFormatTranslateMCLegacy.blockToRctEmCand(), HLTObjectsMonitor.bookHistograms(), BTagEntry.BTagEntry(), MuonGeometryConstantsBuild.build(), HcalSimParametersFromDD.build(), MTDParametersFromDD.build(), FWSiStripDigiProxyBuilder.build(), FWSimTrackProxyBuilder.build(), FWSiPixelDigiProxyBuilder.build(), FWTrackHitsDetailView.build(), FWConvTrackHitsDetailView.build(), PFClusterFromHGCalTrackster.buildClusters(), SiStripCondObjBuilderFromDb.buildFECRelatedObjects(), SiStripCondObjBuilderFromDb.buildFEDRelatedObjects(), CSCSegAlgoST.buildSegments(), CSCTFTrackBuilder.buildTracks(), edm::TypeWithDict.byName(), ticl::TracksterP4FromEnergySum.calcP4(), PrimaryVertexResolution::Plots.calculateAndFillResolution(), Quantile.calculateQ(), MeasurementSensor2D.calculateSimulatedValue(), MeasurementCOPS.calculateSimulatedValue(), trigger::TriggerEventWithRefs.calometSlice(), CastorCtdcUnpacker.CastorCtdcUnpacker(), CastorUnpacker.CastorUnpacker(), edm::service::MessageServicePSetValidation.catBoolRestriction(), edm::service::MessageServicePSetValidation.categoryPSets(), edm::service::MessageServicePSetValidation.catInts(), edm::service::MessageServicePSetValidation.catNone(), edm::service::MessageServicePSetValidation.catNoPSets(), ME0SegmentAlgorithm.chainHits(), GEMSegmentAlgorithm.chainHits(), CSCSegAlgoST.chainHits(), ClusterVariables.charge(), SiStripClusterInfo.charge(), CosmicGenFilterHelix.charge(), JetCharge.chargeFromRef(), JetCharge.chargeFromValIterator(), SiStripClusterInfo.chargeLR(), CSCDCCExaminer.check(), trackerDTC::Setup.checkGeometry(), ClusterTPAssociation.checkKeyProductID(), SimpleCosmicBONSeeder.checkNoisyModules(), OniaPhotonConversionProducer.checkTkVtxCompatibility(), MuonTrajectoryCleaner.clean(), StorableDoubleMap< T >.clear(), edm::IndexSet.clear(), PixelThresholdClusterizer.clear_buffer(), SiStripConfigDb.clearAnalysisDescriptions(), SiStripConfigDb.clearDcuDetIds(), SiStripConfigDb.clearDeviceDescriptions(), SiStripConfigDb.clearFedConnections(), SiStripConfigDb.clearFedDescriptions(), Phase2TrackerClusterizerAlgorithm.clearMatrix(), helper::CandDecayStoreManager.cloneAndStore(), helper::GsfElectronCollectionStoreManager.cloneAndStore(), helper::MuonCollectionStoreManager.cloneAndStore(), helper::TrackCollectionStoreManager.cloneAndStore(), helper::CollectionStoreManager< OutputCollection, ClonePolicy >.cloneAndStore(), SiStripFineDelayHit.closestCluster(), Trajectory.closestMeasurement(), CSCSegAlgoPreClustering.clusterHits(), ME0SegmentAlgorithm.clusterHits(), GEMSegmentAlgorithm.clusterHits(), CSCSegAlgoST.clusterHits(), MTDThresholdClusterizer.clusterize(), ThreeThresholdAlgorithm.clusterizeDetUnit_(), PixelThresholdClusterizerForBricked.clusterizeDetUnitT(), PixelThresholdClusterizer.clusterizeDetUnitT(), cms::DDCompactView::get< std::vector< double > >(), egammaisolation::EgammaRecHitExtractor.collect(), DCCTBEventBlock.compare(), trigger::TriggerEventWithRefs.compositeSlice(), convertFile(), SiStripRawProcessingAlgorithms.convertVirginRawToHybrid(), PixelThresholdClusterizer.copy_to_buffer(), pat::EventHypothesis.count(), TTBV.count(), hcaldqm::utilities.crate2fed(), DefaultFFTJetObjectFactory< AbsFFTSpecificScaleCalculator >.create(), SiStripAPVRestorer.createCMMapCMstored(), LegacyIOHelper.createDirectoryIfNeededAndCd(), DTDigiToRaw.createFedBuffers(), RPCStripsRing.createOtherConnections(), LaserSorter.createOutStream(), RPCStripsRing.createRefConnections(), CSCFileReader.CSCFileReader(), DDG4ProductionCuts.dd4hepInitialize(), dd_error_scan(), DDIsValid(), edm.decode(), CastorHitCorrection.delay(), PhysicsTools::VarProcessor.deriv(), edm::service::MessageServicePSetValidation.destinationPSets(), PixelDigiCollection.detIDs(), CTPPSPixelDigiCollection.detIDs(), DigiCollectionFP420.detIDs(), ClusterCollectionFP420.detIDs(), SiStripDetCabling.detNumber(), SiStripTFile.dirContent(), jsoncollector::DataPoint.discardCollected(), edm::MixingModule.doPileUp(), TICLTrackstersEdgesValidation.dqmAnalyze(), BrilClient.dqmEndLuminosityBlock(), Pixel3DDigitizerAlgorithm.drift(), LMFDat.dump(), TrackstersMergeProducer.dumpTrackster(), XrdAdaptor::XrdReadStatistics.elapsedNS(), trigger::TriggerEventWithRefs.electronSlice(), EmbeddingLHEProducer.EmbeddingLHEProducer(), FWLiteEnabler.enable(), CmsShowNavigator::FileQueue_t.end(), ElectronCalibrationUniv.endJob(), reco::HcalNoiseRBXArray.endRBX(), HLTMuonMatchAndPlotContainer.endRun(), root::RooFitFunction< X, Expr >.evaluate(), MagFieldConfig.expandList(), HLTConfigData.extract(), hcaldqm::utilities.fed2crate(), sistrip::FEDBufferPayload.FEDBufferPayload(), EcalCondDBInterface.fetchDCSPTMTempList(), DCSPTMTempList.fetchValuesForECIDAndTime(), PFJetMonitor.fill(), MkFitEventOfHitsProducer.fill(), gainCalibHelper::SiPixelGainCalibrationValueComparisonBase< myType, PayloadType >.fill(), EmbeddingLHEProducer.fill_lhe_with_particle(), HGVHistoProducerAlgo.fill_trackster_histos(), edmNew.fillCollectionForThinning(), GenSpecificAlgo.fillCommonMETData(), lhef.fillHeader(), CaloSteppingAction.fillHit(), MuonShowerInformationFiller.fillHitsByStation(), GenParticleProducer.fillIndices(), Py8toJetInput.fillJetAlgoInput(), lhef.fillLines(), Phase2TrackerClusterizerAlgorithm.fillMatrix(), sistrip::FEDEmulator.fillMedians(), MuonMesh.fillMesh(), NPUTablesProducer.fillNPUObjectTable(), QcdLowPtDQM.fillPixels(), FWTGeoRecoGeometry::Info.fillPoints(), FWRecoGeometryESProducer.fillPoints(), CastorShowerLibraryMaker.FillShowerEvent(), GlobalDigisProducer.fillTrk(), GlobalDigisAnalyzer.fillTrk(), edm::RefToBaseVector< T >.fillView(), edm::PtrVector< T >.fillView(), RPCStripsRing.fillWithVirtualStrips(), MultiCandGenEvtSelector.filter(), EcalGenEvtSelector.filter(), EcalGenEvtSelectorFrag.filter(), HadronDecayGenEvtSelector.filter(), PartonHadronDecayGenEvtSelector.filter(), cms::MTCCHLTrigger.filter(), cms::TECClusterFilter.filter(), cms::ClusterMTCCFilter.filter(), ErrorSummaryFilter.filter(), HFFilter.filter(), cms::DDFilteredView.filter(), RPCStripsRing.filterOverlapingChambers(), reco::tau.filterPFCandidates(), find(), HcalIndexLookup.find(), FWGeometry.find(), FourVectorHLT::PathInfoCollection.find(), BTVHLTOfflineSource::PathInfoCollection.find(), cms::DDFilteredView.find(), HLTInclusiveVBFSource::PathInfoCollection.find(), JetMETHLTOfflineSource::PathInfoCollection.find(), LA_Filler_Fitter.find_rebin(), SiStripConfigDb.findDcuDetId(), math::Graph< N, E >.findRoots(), shallow.findTrackIndex(), edm::typelookup.findType(), StraightTrackAlignment.finish(), BeamMonitor.FitAndFill(), FakeBeamMonitor.FitAndFill(), Phase2TrackerDigitizerAlgorithm.fluctuateEloss(), FsmwClusterizer1DNameSpace.fsmw(), PVValHelper.generateBins(), pat::PATObject< ObjectType >.genParticleById(), MuonGeometryNumbering.geoHistoryToBaseNumber(), cms::MuonNumbering.get(), pat::EventHypothesis.get(), SiPixelClusterShapeCache.get(), reco::tau::RecoTauConstructor.get(), L1UpgradeTfMuonTreeProducer.getAlgoFwVersion(), edm::ParameterSet.getAllFileInPaths(), QuickTrackAssociatorByHitsImpl.getAllSimTrackIdentifiers(), SiStripConfigDb.getAnalysisDescriptions(), MuonBaseNumber.getBaseNo(), egHLT::ComCodes.getCode(), egHLT::TrigCodes.getCode(), hcalCalib.GetCoefFromMtrxInvOfAve(), MuonShowerInformationFiller.getCompatibleDets(), HLTScalersClient::CountLSFifo_t.getCount(), SiStripConfigDb.getDcuDetIds(), L1MuBMLUTHandler.getDeltaPhi(), L1MuDTPhiLut.getDeltaPhi(), EcalElectronicsMapping.getDetId(), mySiStripNoises.getDetIds(), SiStripNoises.getDetIds(), SiStripPedestals.getDetIds(), SiPixelGainCalibrationOffline.getDetIds(), SiPixelGainCalibration.getDetIds(), SiPixelGainCalibrationForHLT.getDetIds(), SiStripBadStrip.getDetIds(), HDQMSummary.getDetIds(), SiStripSummary.getDetIds(), SiStripThreshold.getDetIds(), HDetIdAssociator.getDetIdsCloseToAPoint(), HDetIdAssociator.getDetIdsInACone(), SiStripConfigDb.getDeviceDescriptions(), SiStripMonitorDigi.getDigiSourceIndex(), TrackAssociatorByHitsImpl.getDoubleCount(), EcalElectronicsMapping.getElectronicsId(), SiStripConfigDb.getFedConnections(), SiStripConfigDb.getFedDescriptions(), GlobalOptionMgr.getGlobalOption(), GlobalOptionMgr.getGlobalOptionValue(), SiStripDetVOff.getHVoffCounts(), edm::DetSetVector< T >.getIds(), cond::persistency::RunInfoEditor.getLastInserted(), StripCompactDigiSimLinks.getLinks(), RPCLogCone.getLogStripDigisIdxs(), SiStripDetVOff.getLVoffCounts(), edm::PrincipalGetAdapter.getManyByType(), LCTContainer.getMatched(), TrackAssociatorByHitsImpl.getMatchedIds(), MuonAssociatorByHitsHelper.getMatchedIds(), CastorShowerLibraryMaker.GetMissingEnergy(), HcalSimParametersFromDD.getNames(), HcalTB06BeamParametersFromDD.getNames(), edm::ParameterSet.getNamesByCode_(), RPCDBPerformanceHandler.getNewObjects(), popcon::EcalADCToGeVHandler.getNewObjects(), BsJpsiPhiFilter.getNextBs(), cms::DDFilteredView.getNextValue(), ApvAnalysisFactory.getNoise(), trigger::TriggerEventWithRefs.getObjects(), trigger::TriggerRefsCollections.getObjects(), TrackerGeometryUtils.getOuterTrackerDetIds(), DQMImplNet< DQMNet::Object >.getPeer(), DPFIsolation.getPredictions(), L1MuBMLUTHandler.getPt(), L1MuDTPtaLut.getPt(), dqm::impl::MonitorElement.getQReport(), cond::persistency::IOV::Table.getRange(), ApvAnalysisFactory.getRawNoise(), TrackerGeometryUtils.getSiStripDetIds(), TrackAssociatorByPositionImpl.getState(), MuonBaseNumber.getSuperNo(), SiStripPI.getTheRange(), AlignmentPI.getTheRange(), EcalElectronicsMapping.getTriggerElectronicsId(), HGCalWaferType.getType(), hcaldqm::quantity.getValue_Crate(), hcaldqm::quantity.getValue_CrateuTCA(), hcaldqm::quantity.getValue_CrateVME(), hcaldqm::quantity.getValue_FED(), hcaldqm::quantity.getValue_FEDuTCA(), hcaldqm::quantity.getValue_FEDVME(), GenWeightsTableProducer.globalBeginRun(), OMTFConfiguration.globalPhiStart(), edm::RootPrimaryFileSequence.goToEvent(), HcalDigisClient.HcalDigisEndjob(), reco::Photon.hcalOverEcal(), reco::GsfElectron.hcalOverEcal(), reco::Photon.hcalOverEcalBc(), reco::GsfElectron.hcalOverEcalBc(), reco::Photon.hcalTowerSumEt(), reco::GsfElectron.hcalTowerSumEt(), reco::Photon.hcalTowerSumEtBc(), reco::GsfElectron.hcalTowerSumEtBc(), HcalTrigPrimDigiProducer.HcalTrigPrimDigiProducer(), FastFedCablingHistograms.histoAnalysis(), HistoAnalyzer< C >.HistoAnalyzer(), funct::HistoPdf.HistoPdf(), cms::DDFilteredView.history(), ctfseeding::HitExtractorSTRP.hits(), track_associator.hitsToClusterRefs(), HLTPixelAsymmetryFilter.hltFilter(), hsm_1d_returning_iterators(), SiStripAPVRestorer.hybridEmulationInspect(), RunInfoUpdate.import(), cond::persistency.importIovs(), L1TPhase2CorrelatorOffline::InCone.InCone(), edm::ProductResolverIndexHelper.indexToIndexAndNames(), funct::HistoPdf.init(), JetCorrectorParametersHelper.init(), MTDDetTray.init(), MuDetRod.init(), fit::RootMinuit< Function >.init(), FedRawDataInputSource.initFileList(), TrackBuildingAnalyzer.initHisto(), edm::ProductSelector.initialize(), FWGeometry.initMap(), egammaTools::EgammaDNNHelper.initScalerFiles(), HcalSimParametersFromDD.isItHF(), npstat.isNonDecreasing(), npstat.isNonIncreasing(), RPCCosmicSeedrecHitFinder.isouterLayer(), npstat.isStrictlyDecreasing(), AbsHcalFunctor.isStrictlyDecreasing(), npstat.isStrictlyIncreasing(), AbsHcalFunctor.isStrictlyIncreasing(), ApvAnalysisFactory.isUpdating(), trigger::TriggerEventWithRefs.jetSlice(), trigger::TriggerEventWithRefs.l1emSlice(), trigger::TriggerEventWithRefs.l1etmissSlice(), trigger::TriggerEventWithRefs.l1hfringsSlice(), trigger::TriggerEventWithRefs.l1jetSlice(), trigger::TriggerEventWithRefs.l1muonSlice(), trigger::TriggerEventWithRefs.l1tegammaSlice(), trigger::TriggerEventWithRefs.l1tetsumSlice(), trigger::TriggerEventWithRefs.l1thpspftauSlice(), trigger::TriggerEventWithRefs.l1tjetSlice(), trigger::TriggerEventWithRefs.l1tmuonSlice(), trigger::TriggerEventWithRefs.l1tpfjetSlice(), trigger::TriggerEventWithRefs.l1tpftauSlice(), trigger::TriggerEventWithRefs.l1tpftrackSlice(), trigger::TriggerEventWithRefs.l1ttauSlice(), trigger::TriggerEventWithRefs.l1ttkeleSlice(), trigger::TriggerEventWithRefs.l1ttkemSlice(), trigger::TriggerEventWithRefs.l1ttkmuonSlice(), HGVHistoProducerAlgo.layerClusters_to_CaloParticles(), HGVHistoProducerAlgo.layerClusters_to_SimClusters(), reco::tau.leadCand(), SimpleNavigationSchool.linkNextLargerLayer(), DefaultFFTJetRcdMapper< FFTPFJetCorrectorSequence >.load(), fftjetcms::FFTJetInterface.loadInputCollection(), TrajectoryManager.loadSimHits(), RectangularPixelTopology.localY(), edm.LoggedErrorsOnlySummary(), edm.LoggedErrorsSummary(), edm::service::MessageServicePSetValidation.lookForMatch(), edm::VectorInputSource.loopSpecified(), DDErrorDetection.lp_cpv(), edm::InputSource.lumiLimitReached(), cond.m_index(), main(), RPCFakeCalibration.makeCls(), makeCompositeCandidate(), makeCompositeCandidateWithRefsToMaster(), TSToSCAssociatorByEnergyScoreImpl.makeConnections(), MultiClusterAssociatorByEnergyScoreImpl.makeConnections(), LCToSCAssociatorByEnergyScoreImpl.makeConnections(), LCToCPAssociatorByEnergyScoreImpl.makeConnections(), TSToSimTSAssociatorByEnergyScoreImpl.makeConnections(), DTGeometryValidate.makeHistogram(), GEMGeometryValidate.makeHistogram(), RPCGeometryValidate.makeHistogram(), ME0GeometryValidate.makeHistogram(), CSCGeometryValidate.makeHistogram(), FittedEntriesManager.MakeHistos(), RPCFakeCalibration.makeNoise(), fireworks.makeRhoPhiSuperCluster(), fireworks.makeRhoZSuperCluster(), ticl::PatternRecognitionbyCLUE3D< TILES >.makeTracksters(), ticl::PatternRecognitionbyCA< TILES >.makeTracksters(), SiStripRecHitMatcher.match(), CSCStubMatcher.matchALCTsToSimTrack(), CSCStubMatcher.matchCLCTsToSimTrack(), CSCStubMatcher.matchLCTsToSimTrack(), CSCStubMatcher.matchMPLCTsToSimTrack(), dqmservices::DQMStreamerReader.matchTriggerSel(), hgcal_clustering.max_index(), SiStripClusterInfo.maxCharge(), SiStripClusterInfo.maxIndex(), helpers::MCTruthPairSelector< T >.MCTruthPairSelector(), edm.merge(), jsoncollector::DataPoint.mergeAndRetrieveValue(), jsoncollector::DataPoint.mergeAndSerialize(), cms::DDFilteredView.mergedSpecifics(), ticl::PatternRecognitionbyCA< TILES >.mergeTrackstersTRK(), metsig::SignPFSpecificAlgo.mkSignifMatrix(), GenSpecificAlgo.mkSpecificGenMETData(), l1t::MTF7Payload.MTF7Payload(), MultiTrackValidator.MultiTrackValidator(), trigger::TriggerEventWithRefs.muonSlice(), reco::Mustache.MustacheID(), CmsTrackerStringToEnum.name(), cms::dd.name(), cms::dd.name_from_value(), L1CaloHcalScaleConfigOnlineProd.newObject(), CSCFileReader.nextEventFromFUs(), edm::service::MessageServicePSetValidation.noCoutCerrClash(), edm::service::MessageServicePSetValidation.noDuplicates(), edm::service::MessageServicePSetValidation.noKeywords(), edm::service::MessageServicePSetValidation.noneExcept(), edm::service::MessageServicePSetValidation.noNoncategoryPsets(), edm::service::MessageServicePSetValidation.noOtherPsets(), NtpProducer< C >.NtpProducer(), cmdline.OneShotExtract< std::string >(), TrackerDpgAnalysis.onTrack(), TrackerDpgAnalysis.onTrackAngles(), DDVector.operator std::vector< int >(), SubsetHsmModeFinder3d.operator()(), MtvClusterizer1D< T >.operator()(), reco::parser::MethodArgumentSetter.operator()(), l1tVertexFinder::RecoVertex< T >.operator+=(), operator<<(), OOTPileupCorrectionColl.operator==(), StorableDoubleMap< T >.operator==(), FFTJetDict< Key, T, Compare, Allocator >.operator[](), ReadMapType< std::map< std::string, double > >.operator[](), edm::DetSetVector< T >.operator[](), l1t::stage2::RegionalMuonGMTPacker.packTF(), triggerExpression.parse(), TrackerDetIdSelector.passSelection(), SiPixelFedCablingMap.pathToDetUnitHasDetUnit(), pat::PATVertexAssociationProducer.PATVertexAssociationProducer(), GaussianSumUtilities1D.pdfComponents(), trigger::TriggerEventWithRefs.pfjetSlice(), trigger::TriggerEventWithRefs.pfmetSlice(), trigger::TriggerEventWithRefs.pftauSlice(), l1tpf_calo::Phase1GridBase.Phase1GridBase(), Phase2OTtiltedBarrelLayer.Phase2OTtiltedBarrelLayer(), CmsTrackerPhase1DiskBuilder< FilteredView >.PhiPosNegSplit_innerOuter(), CmsTrackerPhase2TPDiskBuilder< FilteredView >.PhiPosNegSplit_innerOuter(), trigger::TriggerEventWithRefs.photonSlice(), fireworks.pixelLocalY(), trigger::TriggerEventWithRefs.pixtrackSlice(), MODCCSHFDat.populateClob(), IODConfig.populateClob(), precomputed_value_sort(), edm::storage::LocalCacheFile.prefetch(), emtf::Forest.prepareRandomSubsample(), L1MuDTPtaLut.print(), L1MuDTPhiLut.print(), L1GtConditionEvaluation.print(), l1t::ConditionEvaluation.print(), L1RCTParameters.print(), L1GtBoard.print(), LHCInfo.print(), L1MuBMLUTHandler.print_phi_lut(), L1MuBMLUTHandler.print_pta_lut(), print_trigger_collection(), SiStripConfigDb.printAnalysisDescriptions(), triton_utils.printColl(), SiStripConfigDb.printDeviceDescriptions(), SiStripConfigDb.printFedConnections(), SiStripConfigDb.printFedDescriptions(), fit::RootMinuit< Function >.printParameters(), TrackstersMergeProducer.printTrackstersDebug(), magneticfield.printUniqueNames(), PrimitiveSelection.process(), helper::ClusterStorer.processClusters(), l1t::Stage2Layer2DemuxJetAlgoFirmwareImp1.processEvent(), TrackingParticleRefMuonProducer.produce(), SETPatternRecognition.produce(), TrackingParticleBHadronRefSelector.produce(), MultiClustersFromTrackstersProducer.produce(), MuIsoDepositProducer.produce(), LowPtGsfElectronSeedValueMapsProducer.produce(), reco::modulesNew::MCTruthCompositeMatcher.produce(), CandIsoDepositProducer.produce(), TICLCandidateFromTrackstersProducer.produce(), NtpProducer< C >.produce(), HIPixelClusterVtxProducer.produce(), Phase2Tracker::Phase2TrackerDigiProducer.produce(), pat::PATVertexAssociationProducer.produce(), citk::PFIsolationSumProducerForPUPPI.produce(), CandIsolatorFromDeposits.produce(), PixelClusterSelectorTopBottom.produce(), MuonReSeeder.produce(), StripClusterSelectorTopBottom.produce(), TrackstersProducer.produce(), MuonNumberingESProducer.produce(), TrackListMerger.produce(), ClusterCompatibilityProducer.produce(), PFCandIsolatorFromDeposits.produce(), citk::PFIsolationSumProducer.produce(), dqmBmtfAlgoSelector::L1TBMTFAlgoSelector.produce(), l1t::L1TRawToDigi.produce(), GenHIEventProducer.produce(), tmtt::TMTrackProducer.produce(), L1CaloJetProducer.produce(), reco::modules::CosmicTrackSplitter.produce(), reco::modules::TrackerTrackHitFilter.produce(), PhotonIDValueMapProducer.produce(), L1EGCrystalClusterEmulatorProducer.produce(), SiStripFineDelayHit.produceNoTracking(), ecaldqm::MLClient.producePlots(), edm::ProductSelectorRules.ProductSelectorRules(), PixelDigiCollection.put(), CTPPSPixelDigiCollection.put(), DigiCollectionFP420.put(), TrackCollectionFP420.put(), ClusterCollectionFP420.put(), RecoCollectionFP420.put(), PreMixingSiStripWorker.put(), ClusterCollectionFP420.putclear(), RecoCollectionFP420.putclear(), TrackCollectionFP420.putclear(), DigiCollectionFP420.putclear(), edm::DataMixingSiStripRawWorker.putSiStrip(), BeamHaloNavigationSchool.reachableFromHorizontal(), cond::FileReader.read(), DTConfigDBProducer.readDTCCBConfig(), CSCFileReader.readFU(), CSCTFPtLUT.readLUT(), CSCSectorReceiverLUT.readLUTsFromFile(), Model.readMeasurementsFromFile(), CocoaDaqReaderText.ReadNextEvent(), CSCFileReader.readRUI(), jsoncollector::FileIO.readStringFromFile(), Model.readSystemDescription(), edm::storage::LocalCacheFile.readv(), edm::storage::XrdFile.readv(), FedRawDataInputSource.readWorker(), Phase1PixelMaps.rescaleAllBarrel(), Phase1PixelMaps.rescaleAllForward(), reco::TrackJet.resetCharge(), Phase1PixelMaps.retrieveCorners(), SiStripPsuDetIdMap.retrieveDcuDeviceAddresses(), EcalBaseNumber.reverse(), root::RooFitFunction< X, Expr >.RooFitFunction(), CSCTFMuonSorter.run(), fit::RootMinuitCommands< Function >.run(), L1MuBMTrackFinder.run(), DTLocalTriggerTest.runClientDiagnostic(), DTLocalTriggerTPTest.runClientDiagnostic(), DTLocalTriggerEfficiencyTest.runClientDiagnostic(), FWFileEntry.runFilter(), RPCFinalSorter.runFinalSorter(), RPCHalfSorter.runHalf(), emtf::Forest.saveSplitValues(), MuonCSCSeedFromRecHits.seed(), tmtt::TrkRZfilter.seedFilter(), MuonOverlapSeedFromRecHits.seeds(), MultiTrackSelector.select(), HIMultiTrackSelector.select(), DBoxMetadataHelper.set_difference(), DBoxMetadataHelper.set_intersection(), DCSPTMTemp.setEnd(), MODCCSHFDat.setFile(), EcalRecHitWorkerSimple.setFlagBits(), GlobalOptionMgr.setGlobalOption(), CTPPSOpticalFunctionsESSource.setIntervalFor(), PPSAssociationCutsESSource.setIntervalFor(), CTPPSPixelDAQMappingESSourceXML.setIntervalFor(), TotemDAQMappingESSourceXML.setIntervalFor(), ihd::RegionIndex.setLayerSetsEnd(), ODLTCConfig.setParameters(), ODTTCFConfig.setParameters(), ODTTCciConfig.setParameters(), ODDCCConfig.setParameters(), ODSRPConfig.setParameters(), fit::RootMinuit< Function >.setParameters(), ODLaserConfig.setParameters(), cond.setPermissionData(), gen::Pythia6Service.setPYUPDAParams(), RunIOV.setRunEnd(), gen::Pythia6Service.setSLHAParams(), MODRunIOV.setSubRunEnd(), MonRunIOV.setSubRunEnd(), edm::storage::StorageFactory.setTempDir(), FWPFTrackUtils.setupLegoTrack(), edm::Event.size(), HcalHitSelection.skim(), jsoncollector::DataPoint.snap(), jsoncollector::DataPoint.snapStreamAtomic(), HGCalImagingAlgo.sort_by_delta(), hgcal::ClusterTools.sort_by_z(), hgcal_clustering.sorted_indices(), emtf::Forest.sortEventVectors(), PixelInactiveAreaFinder::InactiveAreas.spansAndLayerSets(), split(), TrackingMaterialAnalyser.split(), DD4hep_TrackingMaterialAnalyser.split(), SimpleNavigationSchool.splitForwardLayers(), LumiCalculator.splitpathstr(), TrackCollectionFP420.stationIDs(), RecoCollectionFP420.stationIDs(), edm::service::MessageServicePSetValidation.statisticsPSets(), edm.stemFromPath(), SiStripZeroSuppression.storeCMN(), TTBV.str(), fit::RootMinuitCommands< Function >.string2double(), pat::strbitset.strings(), strip_process_name(), MkFitProducer.stripClusterChargeCut(), StripSubClusterShapeFilterBase.StripSubClusterShapeFilterBase(), FastLinearCMNSubtractor.subtract_(), MedianCMNSubtractor.subtract_(), PercentileCMNSubtractor.subtract_(), PTStatistics.sum(), reco::tau.sumPFVector(), SiStripRawProcessingAlgorithms.suppressProcessedRawData(), SiStripRawProcessingAlgorithms.suppressVirginRawData(), edm::TypeWithDict.templateArgumentAt(), edm::TypeWithDict.templateName(), TkStripMeasurementDet.testStrips(), th1ToFormulaBinTree(), Thrust.Thrust(), TrackAlgoPriorityOrder.TrackAlgoPriorityOrder(), TrackMVAClassifierBase.TrackMVAClassifierBase(), HGVHistoProducerAlgo.tracksters_to_SimTracksters(), pat::TriggerEvent.triggerObjectMatchResult(), dqmservices::DQMStreamerReader.triggerSel(), HLTScalersClient::CountLSFifo_t.trim_(), CmsTrackerStringToEnum.type(), CSCSPEvent.unpack(), sistrip::fedchannelunpacker::detail.unpackRawW(), sistrip::fedchannelunpacker::detail.unpackZSW(), FastFedCablingHistosUsingDb.update(), ApvAnalysisFactory.update(), CaloSteppingAction.update(), sistrip::RawToDigiUnpacker.update(), HLTScalersClient::CountLSFifo_t.update(), FWTableViewTableManager.updateEvaluators(), L1TOccupancyClientHistogramService.updateHistogramEndRun(), ApvAnalysisFactory.updatePair(), PixelInactiveAreaFinder.updatePixelDets(), CrossingPtBasedLinearizationPointFinder.useAllTracks(), CrossingPtBasedLinearizationPointFinder.useFullMatrix(), TTBV.val(), cms::dd.value(), SiStripClusterInfo.variance(), cms::DDNamespace.vecDbl(), cms::DDNamespace.vecFloat(), edm::service::MessageServicePSetValidation.vStringsCheck(), AlcaBeamSpotManager.weight(), QuickTrackAssociatorByHitsImpl.weightedNumberOfTrackClusters(), SimpleNavigableLayer.wellInside(), edm::service::MessageServicePSetValidation.wildcard(), XMLConfigWriter.writeConnectionsData(), LMFUnique.writeDB(), LaserSorter.writeIndexTable(), edm::RootOutputFile.writeProductDescriptionRegistry(), GctFormatTranslateMCLegacy.writeRctEmCandBlocks(), ZdcUnpacker.ZdcUnpacker(), CandIsolatorFromDeposits.~CandIsolatorFromDeposits(), DefaultFFTJetObjectFactory< AbsFFTSpecificScaleCalculator >.~DefaultFFTJetObjectFactory(), DefaultFFTJetRcdMapper< FFTPFJetCorrectorSequence >.~DefaultFFTJetRcdMapper(), HistoAnalyzer< C >.~HistoAnalyzer(), and PFCandIsolatorFromDeposits.~PFCandIsolatorFromDeposits().

string dataset.firstRun = "207800"

Definition at line 936 of file dataset.py.

Referenced by SiStripLorentzAngleCalibration.beginRun(), SiPixelLorentzAngleCalibration.beginRun(), MillePedeAlignmentAlgorithm.beginRun(), TkModuleGroupSelector.createModuleGroups(), SiPixelDcsInfo.dqmEndLuminosityBlock(), edm::SetRunHelper.setForcedRunOffset(), and SiPixelDcsInfo.SiPixelDcsInfo().

string dataset.help = 'print absolute path'

Definition at line 22 of file dataset.py.

dataset.info = notoptions.noinfo

Definition at line 46 of file dataset.py.

tuple dataset.jsonFile
Initial value:
1 = ( '/afs/cern.ch/cms/CAF/CMSCOMM/COMM_DQM/certification/'
2  'Collisions12/8TeV/Prompt/'
3  'Cert_190456-207898_8TeV_PromptReco_Collisions12_JSON.txt' )

Definition at line 931 of file dataset.py.

dataset.jsonPath = jsonFile,

Definition at line 939 of file dataset.py.

list dataset.name = args[0]

Definition at line 45 of file dataset.py.

tuple dataset.parser = OptionParser()

Definition at line 14 of file dataset.py.

tuple dataset.run_range = (options.min_run,options.max_run)

Definition at line 48 of file dataset.py.

dataset.user = options.user

Definition at line 44 of file dataset.py.

string dataset.validationfooter
Initial value:
1 = """
2 ] )
3 """

Definition at line 278 of file dataset.py.

string dataset.validationheader
Initial value:
1 = """
2 import FWCore.ParameterSet.Config as cms
3 
4 maxEvents = cms.untracked.PSet( input = cms.untracked.int32(-1) )
5 readFiles = cms.untracked.vstring()
6 secFiles = cms.untracked.vstring()
7 source = cms.Source ("PoolSource",fileNames = readFiles, secondaryFileNames = secFiles)
8 readFiles.extend( [
9 """

Definition at line 268 of file dataset.py.