CMS 3D CMS Logo

 All Classes Namespaces Files Functions Variables Typedefs Enumerations Enumerator Properties Friends Macros Groups Pages
List of all members | Public Member Functions | Private Attributes
ntupleDataFormat._Collection Class Reference
Inheritance diagram for ntupleDataFormat._Collection:
ntupleDataFormat.GluedHits ntupleDataFormat.Phase2OTHits ntupleDataFormat.PixelHits ntupleDataFormat.Seeds ntupleDataFormat.StripHits ntupleDataFormat.TrackingParticles ntupleDataFormat.TrackingVertices ntupleDataFormat.Tracks ntupleDataFormat.Vertices

Public Member Functions

def __getitem__
 
def __init__
 
def __iter__
 
def __len__
 
def size
 

Private Attributes

 _objclass
 
 _sizeBranch
 
 _tree
 

Detailed Description

Adaptor class representing a collection of objects.

Concrete collection classes should inherit from this class.

Definition at line 10 of file ntupleDataFormat.py.

Constructor & Destructor Documentation

def ntupleDataFormat._Collection.__init__ (   self,
  tree,
  sizeBranch,
  objclass 
)
Constructor.

Arguments:
tree        -- TTree object
sizeBranch  -- Name of the branch to be used in size()
objclass    -- Class to be used for the objects in __getitem__()

Definition at line 16 of file ntupleDataFormat.py.

16 
17  def __init__(self, tree, sizeBranch, objclass):
18  """Constructor.
19 
20  Arguments:
21  tree -- TTree object
22  sizeBranch -- Name of the branch to be used in size()
23  objclass -- Class to be used for the objects in __getitem__()
24  """
25  super(_Collection, self).__init__()
26  self._tree = tree
27  self._sizeBranch = sizeBranch
28  self._objclass = objclass

Member Function Documentation

def ntupleDataFormat._Collection.__getitem__ (   self,
  index 
)
Get object 'index' in the collection.

Definition at line 37 of file ntupleDataFormat.py.

References ntupleDataFormat._Collection._objclass, ntupleDataFormat._Collection._tree, and python.cmstools.EventTree._tree.

37 
38  def __getitem__(self, index):
39  """Get object 'index' in the collection."""
40  return self._objclass(self._tree, index)
def ntupleDataFormat._Collection.__iter__ (   self)
Returns generator for the objects.

Definition at line 41 of file ntupleDataFormat.py.

References ntupleDataFormat._Collection._objclass, ntupleDataFormat._Collection._tree, python.cmstools.EventTree._tree, sistrip::SpyUtilities.range(), splitter.FileObj.size, ClusterData.size, OrderedSeedingHits.size(), OrderedMultiHits.size(), OrderedHitPairs.size(), OrderedHitSeeds.size(), OrderedHitTriplets.size(), cond::persistency::GLOBAL_TAG::NAME.size, cond::persistency::TAG::NAME.size, cond::persistency::RUN_INFO::RUN_NUMBER.size, cond::persistency::TAG::TIME_TYPE.size, cond::persistency::GLOBAL_TAG::VALIDITY.size, cond::persistency::RUN_INFO::START_TIME.size, cond::persistency::TAG::OBJECT_TYPE.size, Phase2TrackerClusterizerArray.size(), edm::storage::IOBuffer.size(), reco::ClusterCompatibility.size(), cond::persistency::RUN_INFO::END_TIME.size, PHGCSimAccumulator::DetIdSize.size(), cond::persistency::GLOBAL_TAG::DESCRIPTION.size, cond::persistency::GLOBAL_TAG::RELEASE.size, cond::persistency::TAG::SYNCHRONIZATION.size, SeedConfigSelector.size(), funct::Master< F >.size(), edm::storage::IOPosBuffer.size(), SiPixelErrorsSoA.size(), cond::persistency::GLOBAL_TAG::SNAPSHOT_TIME.size, cond::persistency::TAG::END_OF_VALIDITY.size, Packet.size(), cond::persistency::TAG::DESCRIPTION.size, cond::persistency::GLOBAL_TAG::INSERTION_TIME.size, MixCollection< T >.size(), cond::persistency::O2O_RUN::JOB_NAME.size, TritonMemResource< IO >.size(), cond::persistency::TAG::LAST_VALIDATED_TIME.size, eventstfile.Events.size(), edm::reftobase::RefVectorHolderBase.size(), EcalDataFrame_Ph2.size(), cond::persistency::O2O_RUN::START_TIME.size, tracking::TempMeasurements.size(), EcalTBTDCRawInfo.size(), cond::persistency::RUN_INFO::MAX_RUN_NUMBER.size, btag::SimpleMatrix< T >.size(), edm::MergeableRunProductProcesses.size(), cond::persistency::TAG::INSERTION_TIME.size, EcalPnDiodeDigi.size(), EcalPseudoStripInputDigi.size(), ESDataFrame.size(), CastorTriggerPrimitiveDigi.size(), HcalTriggerPrimitiveDigi.size(), cond::persistency::O2O_RUN::END_TIME.size, SiPixelDigisSoA.size(), CSCOverlapConfigSelector.size(), CaloTSamplesBase< Ttype >.size(), cond::persistency::TAG::MODIFICATION_TIME.size, EcalTimeDigi.size(), PMTDSimAccumulator::DetIdSize.size(), cond::persistency::O2O_RUN::STATUS_CODE.size, SiPixelROCsStatusAndMapping.size, FileBlobCollection.size(), TrackingRecHitPipe.size(), TrackFromVertexConfigSelector.size(), cond::persistency::TAG::PROTECTION_CODE.size, cond::persistency::O2O_RUN::LOG.size, edm::Span< T >.size(), CSCBeamHaloConfigSelector.size(), CaloSamples.size(), helper::CandDecayStoreManager.size(), GsfMultipleScatteringUpdator.size(), SeedingLayerSetsLooper::LayerSet< T >.size(), FQueue< T >.size(), TEveElementIter.size(), l1tpf_calo::Grid.size(), edm::reftobase::RefVectorHolder< REFV >.size(), IntegerCaloSamples.size(), helper::MasterCollection< C1 >.size(), reco::HGCalMultiCluster.size(), CTPPSPixelGainCalibrations.size(), SiPixelQualityProbabilities.size(), MuonGeometryConstants.size(), CSCTrackConfigSelector.size(), EcalDataFrame.size(), CastorDataFrame.size(), HcalCalibDataFrame.size(), ZDCDataFrame.size(), calo::common::AddSize< tags::Ptr >.size, JetCorrectorParametersHelper.size(), sistrip::FEDStripData::ChannelData.size(), edm::reftobase::BaseVectorHolder< T >.size(), HBHEDataFrame.size(), HFDataFrame.size(), HODataFrame.size(), cond::persistency::RUN_INFO::MIN_RUN_NUMBER.size, Phase2TrackerCluster1D.size(), PUEvent::PUMinBiasEvt.size, hgc_digi::HGCCellHitInfo.size, InitMsgBuilder.size(), emtf::Forest.size(), ThirdHitPredictionFromInvLine.size(), SiStripCalTrackConfigSelector.size(), pf2pat::PFCandidateSelectorDefinition.size(), GaussianSumUtilities1D.size(), pf2pat::PFJetSelectorDefinition.size(), EcalEBTriggerPrimitiveDigi.size(), ntupleDataFormat._Collection.size(), edm::EDCollection< T >.size(), EventMsgBuilder.size(), RpcCluster.size(), LHERunInfoProduct::Header.size(), EcalTriggerPrimitiveDigi.size(), FileData.size(), edm::IndexSet.size(), edm::History.size(), calo::common::AddSize< tags::DevPtr >.size, SiPixelFEDChannelContainer.size(), HcalChannelIterator.size(), HcalTTPDigi.size(), SiPixelClusterShapeData.size(), HBHEChannelGroups.size(), HcalItemColl< Item >.size(), MSLayersAtAngle.size(), edm::ContainerMaskTraits< T >.size(), edm::reftobase::IndirectVectorHolder< T >.size(), MillePedeVariables.size(), RecoTrackViewRefSelector.size(), trigger::HLTPrescaleTable.size(), reco::formula::ArrayAdaptor.size(), StringMap.size(), cond::persistency::RUN_INFO::MIN_START_TIME.size, PacketData.size(), CrystalWindowMap.size(), hgc_digi::HGCCellInfo.size, edm::HLTGlobalStatus.size(), MuonConfigSelector.size(), ext::basic_omemstream< Item_t, Traits_t, Allocator_t >.size(), RecoTrackRefSelector.size(), RecoTrackSelector.size(), cond::Binary.size(), DDStrVector.size(), DDVector.size(), FWItemSingleAccessor.size(), PATPrimaryVertexSelector.size(), edm::reftobase::VectorHolder< T, REFVECTOR >.size(), HGCDataFrame< D, S >.size(), edm::EventTime.size(), reco::MuonRecHitCluster.size(), FileBlob.size(), SiPixelPerformanceSummary.size(), SiPixelROCsStatusAndMappingWrapper.size, muonisolation::Cuts.size(), CSCTMBData.size(), TrackConfigSelector.size(), CalibrationInterface< CategoryT, CalibDataT >.size(), HcalIndexLookup.size(), CSCEventData.size(), DDMap.size(), FWItemTVirtualCollectionProxyAccessor.size(), Book.size(), SiPixelArrayBuffer.size(), FWItemAccessorBase.size(), SeedingHitSet.size(), MultiFileBlob.size(), reco::DeDxHitInfo.size(), GsfMaterialEffectsUpdator.size(), ESCondObjectContainer< T >.size(), AlignPCLThresholds.size(), edm::soa::TableExaminer< T >.size(), edm::DataFrame.size(), EZMgrFL< T >.size(), AlignmentCorrelationsStore.size(), TTDTC.size(), HeaderView.size(), DTCache< T, Coll >.size(), edm::storage::File.size(), magneticfield::bLayer.size, FEDRawData.size(), DDHCalForwardAlgo.size, edm::soa::TableExaminerBase.size(), RecHitsSortedInPhi.size(), FTLDataFrameT< D, S, DECODE >.size(), helper::MasterCollection< edm::View< T > >.size(), reco::PFRecHit::Neighbours.size(), edm::FunctionWithDict.size(), reco::Candidate.size, DDI::Store< N, I, K >.size(), DCCTBBlockPrototype.size(), edm::VParameterSetEntry.size(), HLTConfigData.size(), egHLT::TrigCodes.size(), AlignmentExtendedCorrelationsStore.size(), muonisolation::IsolatorByNominalEfficiency::ConeSizes.size(), reco::Vertex.size, l1t::HGCalClusterT< C >.size(), edm::ProcessHistory.size(), SiPixelClusterShapeCache::Field.size, edm::ContainerMask< T >.size(), helper::MuonCollectionStoreManager.size(), ColinearityKinematicConstraint.size, edm::service::TriggerNamesService.size(), LMFCorrCoefDat.size(), SiStripCluster.size(), CSCDDUEventData.size(), AlignableNavigator.size(), cond::persistency::GLOBAL_TAG_MAP::GLOBAL_TAG_NAME.size, L1MuDTSecProcMap.size(), nanoaod::FlatTable.size(), L1MuBMSecProcMap.size(), cond::persistency::GLOBAL_TAG_MAP::RECORD.size, helper::TrackCollectionStoreManager.size(), ClusterTPAssociation.size(), hcaldqm::ContainerXXX< STDTYPE >.size(), HLTConfigInterface.size(), L1GctUnsignedInt< nBits >.size(), edm::RefToBaseVector< T >.size(), CategoryCriteria< Collection, Classifier >.size(), edm::storage::Storage.size(), cond::persistency::GLOBAL_TAG_MAP::LABEL.size, cond::persistency::GLOBAL_TAG_MAP::TAG_NAME.size, TTBV.size(), DynArray< T >.size(), edm::DetSet< T >.size(), KDTreeNodes< DATA, DIM >.size(), MP7PacketReader.size(), HcalItemCollById< Item >.size(), HLTConfigProvider.size(), LMFDat.size(), cond::persistency::KeyList.size(), edm::Association< C >.size(), edm::soa::TableView< Args >.size(), SiStripLAProfileBooker.size, L1MuDTEtaPatternLut.size(), L1GctTwosComplement< nBits >.size(), InitMsgView.size(), EZArrayFL< T >.size(), edm::OneToValue< CKey, Val, index >.size(), DDValue.size(), L1MuBMTEtaPatternLut.size(), edmNew::DetSet< T >.size(), Alignable.size(), BXVector< T >.size(), edm::pset::Registry.size(), L1MuDTQualPatternLut.size(), edm::VecArray< T, N >.size(), QIE11DataFrame.size(), RecoIdealGeometry.size(), poly< T >.size(), MP7FileReader.size(), PhysicsTools::VarProcessor::ConfigCtx.size(), Selection< C, Selector, StoreContainer >.size(), EcalCondTowerObjectContainer< T >.size(), L1MuBMTQualPatternLut.size(), HiggsValidation::MonitoredDecays.size(), RegionsSeedingHitSets.size(), cond::TagInfo_t.size, amc13::Packet.size(), edm::OccurrenceForOutput.size(), BPHRecoBuilder::BPHGenericCollection.size(), edm::PtrVectorBase.size(), EcalMatacqDigi.size(), edm::OneToOneGeneric< CKey, CVal, index, KeyRefProd, ValRefProd, KeyRef, ValRef >.size(), cond::persistency::PAYLOAD::HASH.size, cond::persistency::PAYLOAD::OBJECT_TYPE.size, EventMsgView.size(), trklet::TrackletLUT.size(), fwlite::ChainEvent.size(), GenJetClosestMatchSelectorDefinition.size(), cond::persistency::PAYLOAD::DATA.size, edm::SingleConsumerQ::OperateBuffer< T >.size(), helper::CollectionStoreManager< OutputCollection, ClonePolicy >.size(), edm::RefVectorBase< T >.size(), QIE10DataFrame.size(), cond::persistency::PAYLOAD::STREAMER_INFO.size, EcalCondObjectContainer< T >.size(), cond::persistency::PAYLOAD::VERSION.size, edm::OneToMany< CKey, CVal, index >.size(), cond::persistency::IOVArray.size(), CTPPSPixelCluster.size(), cond::persistency::PAYLOAD::INSERTION_TIME.size, edm::detail::ThreadSafeRegistry< KEY, T >.size(), edm::TriggerNames.size(), EcalContainer< DetId, T >.size(), HLTConfigDataEx.size(), edm::Path.size(), edm::AssociationVector< KeyRefProd, CVal, KeyRef, SizeType, KeyReferenceHelper >.size(), fwlite::Run.size(), edm::eventsetup::DataProxyProvider::KeyedProxies.size(), pat::eventhypothesis::Looper< T >.size(), cms::cuda::VecArray< T, maxSize >.size(), L1RPCHwConfig.size(), fwlite::MultiChainEvent.size(), METCorrectorParameters.size(), FWItemRandomAccessor< C, V >.size(), fwlite::LuminosityBlock.size(), TkGluedMeasurementDet::HitCollectorForRecHits.size(), edm::OneToManyWithQualityGeneric< CKey, CVal, Q, index, KeyRefProd, ValRefProd, KeyRef, ValRef >.size(), DTTrig.size(), MEtXYcorrectParameters.size(), cond::SmallWORMDict.size(), edm::helper::IndexRangeAssociation.size(), edm::MapOfVectors< K, T >.size(), SummaryGenerator.size(), MTDArrayBuffer.size(), edm::FileIndex.size(), cond::persistency::RunInfoProxy.size(), helper::GsfElectronCollectionStoreManager.size(), cond::persistency::GTProxy.size(), PhysicsTools::VarProcessor::LoopCtx.size(), HGCalConcentratorSuperTriggerCellImpl::SuperTriggerCell.size(), edm::TriggerResultsByName.size(), edm::RefVector< C, T, F >.size(), edm::TypeWithDict.size(), SeedingLayerSetsHits::SeedingLayerSet.size(), AlignmentParameters.size(), jpt::Efficiency.size(), l1tpf_calo::GridData< T >.size(), hitfit::Fit_Result_Vec.size(), FWEventItem.size(), PhysicsTools::Variable::ValueList.size(), cms::cuda::SimpleVector< T >.size(), edm::ProductRegistry.size(), cond::persistency::IOV::TAG_NAME.size, CSCAnalogSignal.size(), cond::persistency::IOV::SINCE.size, cond::persistency::IOV::PAYLOAD_HASH.size, VIterator< Item >.size(), cond::persistency::IOV::INSERTION_TIME.size, HitPixelLayersTPSelector.size(), SiStripFedCabling::ConnsRange.size(), XrdAdaptor::XrdReadStatistics.size(), DTTFBitArray< N >.size(), BitArray< N >.size(), cond::persistency::IOV::SINCE_GROUP.size, KDTreeLinkerAlgo< DATA, DIM >.size(), edm::SortedCollection< T, SORT >.size(), edm::View< T >.size(), TkGluedMeasurementDet::HitCollectorForSimpleHits.size(), DDXMLElement.size(), JetCorrectorParameters.size(), edmNew::dstvdetails::DetSetVectorTrans::Item.size, edm::RangeMap< ID, C, P >.size(), HLTCommonConfig::View.size(), HIProtoTrackSelector.size(), FWItemDetSetAccessor< C, COLL, V >.size(), cond::persistency::IOV::SEQUENCE_SIZE.size, ProcessCallGraph.size(), edm::CompactEventAuxiliaryVector.size(), SiPixelCluster.size(), cond::persistency::IOV::MIN_SINCE.size, HitDoublets.size(), FTLCluster.size(), reco::FlavorHistoryEvent.size(), FRDEventMsgView.size(), cond::persistency::IOV::MAX_SINCE.size, edm::DetSetVector< T >.size(), DTCombinatorialPatternReco::TriedPattern.size(), BPHRecoBuilder::BPHInterfaceCollection< T >.size(), amc::Packet.size(), TkGluedMeasurementDet::HitCollectorForFastMeasurements.size(), edm::SoATuple< Args >.size(), edm::ValueMap< T >.size(), edm::Principal.size(), edm::OwnVector< T, P >.size(), fwlite::Event.size(), HLTCommonConfig.size(), edm::TypeBases.size(), edm::DataFrameContainer.size(), edm::AssociationMap< Tag >.size(), edm::DetSetRefVector< T, C >.size(), FWItemNewDetSetAccessor< C, COLL, V >.size(), esMonitoring.LineHistoryEnd.size, edm::TypeDataMembers.size(), PhysicsTools::BitSet.size(), StMeasurementDetSet.size(), FKDTree< TYPE, numberOfDimensions >.size(), math::Graph< N, E >.size(), edm::soa::Table< Args >.size(), edm::TypeFunctionMembers.size(), edm::ValueMap< T >::const_iterator.size(), cuy.FindIssue.size, reco::CaloCluster.size(), CLookToRead.size, cond::persistency::TAG_AUTHORIZATION::TAG_NAME.size, cond::persistency::TAG_AUTHORIZATION::ACCESS_TYPE.size, cond::persistency::TAG_AUTHORIZATION::CREDENTIAL.size, cond::persistency::TAG_AUTHORIZATION::CREDENTIAL_TYPE.size, FWItemRangeAccessor< C, R, V >.size(), SeedingLayerSetsHits.size(), edm::MultiAssociation< C >.size(), cmsutils::bqueue< T >.size(), CosmicTrackingParticleSelector.size(), PhysicsTools::VarProcessor::ValueIterator.size(), reco::TaggingVariableList.size(), trigger::TriggerEventWithRefs.size(), cond::persistency::TAG_LOG::TAG_NAME.size, cond::persistency::TAG_LOG::EVENT_TIME.size, cond::persistency::TAG_LOG::USER_NAME.size, cond::persistency::TAG_LOG::HOST_NAME.size, cond::persistency::TAG_LOG::COMMAND.size, PFTauSelectorDefinition.size(), cond::persistency::TAG_LOG::ACTION.size, cond::persistency::TAG_LOG::USER_TEXT.size, Json::Value.size(), FWItemMuonDigiAccessor< C, V >.size(), dqmstorepb::PROTOBUF_FINAL.size(), edm::Event.size(), edmNew::DetSetVector< T >::FastFiller.size(), BXVectorAccessor< C >.size(), PxMeasurementDetSet.size(), edmNew::DetSetVector< T >::TSFastFiller.size(), Phase2OTMeasurementDetSet.size(), python.Events.size(), edm::IndexIntoFile::IndexIntoFileItrImpl.size(), edmNew::DetSetVector< T >.size(), edm::ContainerMaskTraits< edmNew::DetSetVector< T > >.size(), edm::IndexIntoFile::IndexIntoFileItr.size(), reco::PatternSet< N >.size(), and CellDB.size().

41 
42  def __iter__(self):
43  """Returns generator for the objects."""
44  for index in range(self.size()):
45  yield self._objclass(self._tree, index)
const uint16_t range(const Frame &aFrame)
def ntupleDataFormat._Collection.__len__ (   self)
Number of objects in the collection.

Definition at line 33 of file ntupleDataFormat.py.

References splitter.FileObj.size, ClusterData.size, OrderedSeedingHits.size(), OrderedHitPairs.size(), OrderedMultiHits.size(), OrderedHitSeeds.size(), OrderedHitTriplets.size(), cond::persistency::GLOBAL_TAG::NAME.size, cond::persistency::TAG::NAME.size, cond::persistency::RUN_INFO::RUN_NUMBER.size, cond::persistency::GLOBAL_TAG::VALIDITY.size, cond::persistency::RUN_INFO::START_TIME.size, cond::persistency::TAG::TIME_TYPE.size, cond::persistency::TAG::OBJECT_TYPE.size, Phase2TrackerClusterizerArray.size(), edm::storage::IOBuffer.size(), reco::ClusterCompatibility.size(), cond::persistency::RUN_INFO::END_TIME.size, PHGCSimAccumulator::DetIdSize.size(), cond::persistency::GLOBAL_TAG::DESCRIPTION.size, cond::persistency::TAG::SYNCHRONIZATION.size, SeedConfigSelector.size(), funct::Master< F >.size(), edm::storage::IOPosBuffer.size(), cond::persistency::GLOBAL_TAG::RELEASE.size, SiPixelErrorsSoA.size(), cond::persistency::GLOBAL_TAG::SNAPSHOT_TIME.size, cond::persistency::TAG::END_OF_VALIDITY.size, Packet.size(), cond::persistency::GLOBAL_TAG::INSERTION_TIME.size, cond::persistency::TAG::DESCRIPTION.size, MixCollection< T >.size(), cond::persistency::O2O_RUN::JOB_NAME.size, cond::persistency::TAG::LAST_VALIDATED_TIME.size, TritonMemResource< IO >.size(), edm::reftobase::RefVectorHolderBase.size(), eventstfile.Events.size(), cond::persistency::O2O_RUN::START_TIME.size, EcalDataFrame_Ph2.size(), EcalTBTDCRawInfo.size(), tracking::TempMeasurements.size(), cond::persistency::RUN_INFO::MAX_RUN_NUMBER.size, btag::SimpleMatrix< T >.size(), edm::MergeableRunProductProcesses.size(), cond::persistency::TAG::INSERTION_TIME.size, EcalPseudoStripInputDigi.size(), EcalPnDiodeDigi.size(), cond::persistency::O2O_RUN::END_TIME.size, ESDataFrame.size(), CastorTriggerPrimitiveDigi.size(), HcalTriggerPrimitiveDigi.size(), SiPixelDigisSoA.size(), CSCOverlapConfigSelector.size(), cond::persistency::TAG::MODIFICATION_TIME.size, CaloTSamplesBase< Ttype >.size(), EcalTimeDigi.size(), PMTDSimAccumulator::DetIdSize.size(), cond::persistency::O2O_RUN::STATUS_CODE.size, SiPixelROCsStatusAndMapping.size, FileBlobCollection.size(), TrackingRecHitPipe.size(), TrackFromVertexConfigSelector.size(), cond::persistency::TAG::PROTECTION_CODE.size, cond::persistency::O2O_RUN::LOG.size, edm::Span< T >.size(), CSCBeamHaloConfigSelector.size(), CaloSamples.size(), helper::CandDecayStoreManager.size(), GsfMultipleScatteringUpdator.size(), FQueue< T >.size(), SeedingLayerSetsLooper::LayerSet< T >.size(), TEveElementIter.size(), l1tpf_calo::Grid.size(), edm::reftobase::RefVectorHolder< REFV >.size(), IntegerCaloSamples.size(), helper::MasterCollection< C1 >.size(), reco::HGCalMultiCluster.size(), CTPPSPixelGainCalibrations.size(), SiPixelQualityProbabilities.size(), MuonGeometryConstants.size(), CSCTrackConfigSelector.size(), EcalDataFrame.size(), CastorDataFrame.size(), HcalCalibDataFrame.size(), ZDCDataFrame.size(), calo::common::AddSize< tags::Ptr >.size, JetCorrectorParametersHelper.size(), sistrip::FEDStripData::ChannelData.size(), edm::reftobase::BaseVectorHolder< T >.size(), HBHEDataFrame.size(), HFDataFrame.size(), HODataFrame.size(), cond::persistency::RUN_INFO::MIN_RUN_NUMBER.size, Phase2TrackerCluster1D.size(), PUEvent::PUMinBiasEvt.size, hgc_digi::HGCCellHitInfo.size, InitMsgBuilder.size(), emtf::Forest.size(), SiStripCalTrackConfigSelector.size(), ThirdHitPredictionFromInvLine.size(), GaussianSumUtilities1D.size(), pf2pat::PFJetSelectorDefinition.size(), pf2pat::PFCandidateSelectorDefinition.size(), EcalEBTriggerPrimitiveDigi.size(), ntupleDataFormat._Collection.size(), edm::EDCollection< T >.size(), EventMsgBuilder.size(), RpcCluster.size(), EcalTriggerPrimitiveDigi.size(), LHERunInfoProduct::Header.size(), FileData.size(), edm::IndexSet.size(), edm::History.size(), calo::common::AddSize< tags::DevPtr >.size, SiPixelFEDChannelContainer.size(), HcalChannelIterator.size(), HcalTTPDigi.size(), SiPixelClusterShapeData.size(), HBHEChannelGroups.size(), HcalItemColl< Item >.size(), edm::ContainerMaskTraits< T >.size(), edm::reftobase::IndirectVectorHolder< T >.size(), MillePedeVariables.size(), MSLayersAtAngle.size(), RecoTrackViewRefSelector.size(), trigger::HLTPrescaleTable.size(), reco::formula::ArrayAdaptor.size(), cond::persistency::RUN_INFO::MIN_START_TIME.size, StringMap.size(), PacketData.size(), CrystalWindowMap.size(), hgc_digi::HGCCellInfo.size, edm::HLTGlobalStatus.size(), MuonConfigSelector.size(), ext::basic_omemstream< Item_t, Traits_t, Allocator_t >.size(), RecoTrackRefSelector.size(), RecoTrackSelector.size(), cond::Binary.size(), DDStrVector.size(), DDVector.size(), FWItemSingleAccessor.size(), PATPrimaryVertexSelector.size(), edm::reftobase::VectorHolder< T, REFVECTOR >.size(), HGCDataFrame< D, S >.size(), edm::EventTime.size(), reco::MuonRecHitCluster.size(), FileBlob.size(), SiPixelPerformanceSummary.size(), SiPixelROCsStatusAndMappingWrapper.size, muonisolation::Cuts.size(), CSCTMBData.size(), TrackConfigSelector.size(), CalibrationInterface< CategoryT, CalibDataT >.size(), HcalIndexLookup.size(), CSCEventData.size(), FWItemTVirtualCollectionProxyAccessor.size(), SiPixelArrayBuffer.size(), Book.size(), DDMap.size(), FWItemAccessorBase.size(), SeedingHitSet.size(), MultiFileBlob.size(), reco::DeDxHitInfo.size(), GsfMaterialEffectsUpdator.size(), ESCondObjectContainer< T >.size(), AlignPCLThresholds.size(), edm::soa::TableExaminer< T >.size(), edm::DataFrame.size(), EZMgrFL< T >.size(), AlignmentCorrelationsStore.size(), TTDTC.size(), HeaderView.size(), DTCache< T, Coll >.size(), magneticfield::bLayer.size, edm::storage::File.size(), FEDRawData.size(), DDHCalForwardAlgo.size, edm::soa::TableExaminerBase.size(), RecHitsSortedInPhi.size(), FTLDataFrameT< D, S, DECODE >.size(), helper::MasterCollection< edm::View< T > >.size(), reco::PFRecHit::Neighbours.size(), edm::FunctionWithDict.size(), reco::Candidate.size, DDI::Store< N, I, K >.size(), DCCTBBlockPrototype.size(), edm::VParameterSetEntry.size(), HLTConfigData.size(), egHLT::TrigCodes.size(), muonisolation::IsolatorByNominalEfficiency::ConeSizes.size(), AlignmentExtendedCorrelationsStore.size(), reco::Vertex.size, l1t::HGCalClusterT< C >.size(), edm::ProcessHistory.size(), SiPixelClusterShapeCache::Field.size, edm::ContainerMask< T >.size(), helper::MuonCollectionStoreManager.size(), ColinearityKinematicConstraint.size, edm::service::TriggerNamesService.size(), LMFCorrCoefDat.size(), SiStripCluster.size(), CSCDDUEventData.size(), AlignableNavigator.size(), cond::persistency::GLOBAL_TAG_MAP::GLOBAL_TAG_NAME.size, L1MuDTSecProcMap.size(), nanoaod::FlatTable.size(), L1MuBMSecProcMap.size(), cond::persistency::GLOBAL_TAG_MAP::RECORD.size, helper::TrackCollectionStoreManager.size(), ClusterTPAssociation.size(), hcaldqm::ContainerXXX< STDTYPE >.size(), HLTConfigInterface.size(), L1GctUnsignedInt< nBits >.size(), edm::RefToBaseVector< T >.size(), CategoryCriteria< Collection, Classifier >.size(), cond::persistency::GLOBAL_TAG_MAP::LABEL.size, edm::storage::Storage.size(), cond::persistency::GLOBAL_TAG_MAP::TAG_NAME.size, TTBV.size(), DynArray< T >.size(), edm::DetSet< T >.size(), KDTreeNodes< DATA, DIM >.size(), MP7PacketReader.size(), HcalItemCollById< Item >.size(), HLTConfigProvider.size(), LMFDat.size(), cond::persistency::KeyList.size(), SiStripLAProfileBooker.size, edm::Association< C >.size(), edm::soa::TableView< Args >.size(), L1MuDTEtaPatternLut.size(), L1GctTwosComplement< nBits >.size(), InitMsgView.size(), EZArrayFL< T >.size(), edm::OneToValue< CKey, Val, index >.size(), DDValue.size(), Alignable.size(), L1MuBMTEtaPatternLut.size(), edmNew::DetSet< T >.size(), BXVector< T >.size(), edm::pset::Registry.size(), L1MuDTQualPatternLut.size(), edm::VecArray< T, N >.size(), QIE11DataFrame.size(), RecoIdealGeometry.size(), MP7FileReader.size(), PhysicsTools::VarProcessor::ConfigCtx.size(), poly< T >.size(), Selection< C, Selector, StoreContainer >.size(), EcalCondTowerObjectContainer< T >.size(), RegionsSeedingHitSets.size(), L1MuBMTQualPatternLut.size(), HiggsValidation::MonitoredDecays.size(), amc13::Packet.size(), cond::TagInfo_t.size, edm::OccurrenceForOutput.size(), EcalMatacqDigi.size(), BPHRecoBuilder::BPHGenericCollection.size(), edm::PtrVectorBase.size(), cond::persistency::PAYLOAD::HASH.size, edm::OneToOneGeneric< CKey, CVal, index, KeyRefProd, ValRefProd, KeyRef, ValRef >.size(), trklet::TrackletLUT.size(), EventMsgView.size(), cond::persistency::PAYLOAD::OBJECT_TYPE.size, fwlite::ChainEvent.size(), GenJetClosestMatchSelectorDefinition.size(), cond::persistency::PAYLOAD::DATA.size, edm::RefVectorBase< T >.size(), edm::SingleConsumerQ::OperateBuffer< T >.size(), cond::persistency::PAYLOAD::STREAMER_INFO.size, QIE10DataFrame.size(), helper::CollectionStoreManager< OutputCollection, ClonePolicy >.size(), edm::OneToMany< CKey, CVal, index >.size(), cond::persistency::PAYLOAD::VERSION.size, cond::persistency::IOVArray.size(), EcalCondObjectContainer< T >.size(), CTPPSPixelCluster.size(), cond::persistency::PAYLOAD::INSERTION_TIME.size, edm::detail::ThreadSafeRegistry< KEY, T >.size(), edm::TriggerNames.size(), edm::Path.size(), HLTConfigDataEx.size(), EcalContainer< DetId, T >.size(), edm::AssociationVector< KeyRefProd, CVal, KeyRef, SizeType, KeyReferenceHelper >.size(), fwlite::Run.size(), edm::eventsetup::DataProxyProvider::KeyedProxies.size(), pat::eventhypothesis::Looper< T >.size(), cms::cuda::VecArray< T, maxSize >.size(), METCorrectorParameters.size(), L1RPCHwConfig.size(), FWItemRandomAccessor< C, V >.size(), TkGluedMeasurementDet::HitCollectorForRecHits.size(), fwlite::MultiChainEvent.size(), fwlite::LuminosityBlock.size(), edm::OneToManyWithQualityGeneric< CKey, CVal, Q, index, KeyRefProd, ValRefProd, KeyRef, ValRef >.size(), DTTrig.size(), MEtXYcorrectParameters.size(), cond::SmallWORMDict.size(), edm::helper::IndexRangeAssociation.size(), edm::MapOfVectors< K, T >.size(), SummaryGenerator.size(), MTDArrayBuffer.size(), edm::FileIndex.size(), cond::persistency::RunInfoProxy.size(), helper::GsfElectronCollectionStoreManager.size(), cond::persistency::GTProxy.size(), PhysicsTools::VarProcessor::LoopCtx.size(), HGCalConcentratorSuperTriggerCellImpl::SuperTriggerCell.size(), edm::TriggerResultsByName.size(), edm::RefVector< C, T, F >.size(), edm::TypeWithDict.size(), SeedingLayerSetsHits::SeedingLayerSet.size(), jpt::Efficiency.size(), AlignmentParameters.size(), l1tpf_calo::GridData< T >.size(), hitfit::Fit_Result_Vec.size(), FWEventItem.size(), PhysicsTools::Variable::ValueList.size(), cms::cuda::SimpleVector< T >.size(), edm::ProductRegistry.size(), cond::persistency::IOV::TAG_NAME.size, CSCAnalogSignal.size(), cond::persistency::IOV::SINCE.size, cond::persistency::IOV::PAYLOAD_HASH.size, VIterator< Item >.size(), cond::persistency::IOV::INSERTION_TIME.size, XrdAdaptor::XrdReadStatistics.size(), SiStripFedCabling::ConnsRange.size(), HitPixelLayersTPSelector.size(), DTTFBitArray< N >.size(), cond::persistency::IOV::SINCE_GROUP.size, BitArray< N >.size(), edm::SortedCollection< T, SORT >.size(), KDTreeLinkerAlgo< DATA, DIM >.size(), edm::View< T >.size(), TkGluedMeasurementDet::HitCollectorForSimpleHits.size(), JetCorrectorParameters.size(), DDXMLElement.size(), HLTCommonConfig::View.size(), edm::RangeMap< ID, C, P >.size(), edmNew::dstvdetails::DetSetVectorTrans::Item.size, HIProtoTrackSelector.size(), FWItemDetSetAccessor< C, COLL, V >.size(), cond::persistency::IOV::SEQUENCE_SIZE.size, ProcessCallGraph.size(), SiPixelCluster.size(), edm::CompactEventAuxiliaryVector.size(), cond::persistency::IOV::MIN_SINCE.size, HitDoublets.size(), FTLCluster.size(), reco::FlavorHistoryEvent.size(), FRDEventMsgView.size(), cond::persistency::IOV::MAX_SINCE.size, edm::DetSetVector< T >.size(), DTCombinatorialPatternReco::TriedPattern.size(), BPHRecoBuilder::BPHInterfaceCollection< T >.size(), amc::Packet.size(), TkGluedMeasurementDet::HitCollectorForFastMeasurements.size(), edm::SoATuple< Args >.size(), edm::ValueMap< T >.size(), edm::OwnVector< T, P >.size(), edm::Principal.size(), fwlite::Event.size(), edm::TypeBases.size(), HLTCommonConfig.size(), edm::DetSetRefVector< T, C >.size(), edm::DataFrameContainer.size(), edm::AssociationMap< Tag >.size(), FWItemNewDetSetAccessor< C, COLL, V >.size(), esMonitoring.LineHistoryEnd.size, edm::TypeDataMembers.size(), PhysicsTools::BitSet.size(), StMeasurementDetSet.size(), FKDTree< TYPE, numberOfDimensions >.size(), math::Graph< N, E >.size(), edm::soa::Table< Args >.size(), edm::TypeFunctionMembers.size(), edm::ValueMap< T >::const_iterator.size(), cuy.FindIssue.size, reco::CaloCluster.size(), CLookToRead.size, cond::persistency::TAG_AUTHORIZATION::TAG_NAME.size, cond::persistency::TAG_AUTHORIZATION::ACCESS_TYPE.size, cond::persistency::TAG_AUTHORIZATION::CREDENTIAL.size, cond::persistency::TAG_AUTHORIZATION::CREDENTIAL_TYPE.size, FWItemRangeAccessor< C, R, V >.size(), SeedingLayerSetsHits.size(), edm::MultiAssociation< C >.size(), cmsutils::bqueue< T >.size(), CosmicTrackingParticleSelector.size(), PhysicsTools::VarProcessor::ValueIterator.size(), reco::TaggingVariableList.size(), trigger::TriggerEventWithRefs.size(), cond::persistency::TAG_LOG::TAG_NAME.size, cond::persistency::TAG_LOG::EVENT_TIME.size, cond::persistency::TAG_LOG::USER_NAME.size, cond::persistency::TAG_LOG::HOST_NAME.size, cond::persistency::TAG_LOG::COMMAND.size, cond::persistency::TAG_LOG::ACTION.size, PFTauSelectorDefinition.size(), cond::persistency::TAG_LOG::USER_TEXT.size, Json::Value.size(), FWItemMuonDigiAccessor< C, V >.size(), dqmstorepb::PROTOBUF_FINAL.size(), edm::Event.size(), edmNew::DetSetVector< T >::FastFiller.size(), BXVectorAccessor< C >.size(), PxMeasurementDetSet.size(), edmNew::DetSetVector< T >::TSFastFiller.size(), Phase2OTMeasurementDetSet.size(), python.Events.size(), edm::IndexIntoFile::IndexIntoFileItrImpl.size(), edmNew::DetSetVector< T >.size(), edm::ContainerMaskTraits< edmNew::DetSetVector< T > >.size(), edm::IndexIntoFile::IndexIntoFileItr.size(), reco::PatternSet< N >.size(), and CellDB.size().

33 
34  def __len__(self):
35  """Number of objects in the collection."""
36  return self.size()
def ntupleDataFormat._Collection.size (   self)
Number of objects in the collection.

Definition at line 29 of file ntupleDataFormat.py.

References ntupleDataFormat._Collection._sizeBranch, ntupleDataFormat._Collection._tree, and python.cmstools.EventTree._tree.

Referenced by ntupleDataFormat._Collection.__iter__(), and ntupleDataFormat._Collection.__len__().

29 
30  def size(self):
31  """Number of objects in the collection."""
32  return int(getattr(self._tree, self._sizeBranch).size())

Member Data Documentation

ntupleDataFormat._Collection._objclass
private

Definition at line 27 of file ntupleDataFormat.py.

Referenced by ntupleDataFormat._Collection.__getitem__(), and ntupleDataFormat._Collection.__iter__().

ntupleDataFormat._Collection._sizeBranch
private

Definition at line 26 of file ntupleDataFormat.py.

Referenced by ntupleDataFormat._Collection.size().

ntupleDataFormat._Collection._tree
private

Definition at line 25 of file ntupleDataFormat.py.

Referenced by ntupleDataFormat._Object.__getattr__(), ntupleDataFormat.BeamSpot.__getattr__(), ntupleDataFormat._Collection.__getitem__(), ntupleDataFormat._Collection.__iter__(), ntupleDataFormat.TrackingNtuple.__iter__(), ntupleDataFormat._SimHitMatchAdaptor._nMatchedSimHits(), ntupleDataFormat._TrackingParticleMatchAdaptor._nMatchedTrackingParticles(), ntupleDataFormat.Event.beamspot(), ntupleDataFormat.TrackingParticle.bestMatchingTrack(), ntupleDataFormat._TrackingParticleMatchAdaptor.bestMatchingTrackingParticle(), ntupleDataFormat._TrackingParticleMatchAdaptor.bestMatchingTrackingParticleFromFirstHit(), ntupleDataFormat.TrackingVertex.daughterTrackingParticles(), ntupleDataFormat.TrackingParticle.decayVertices(), ntupleDataFormat._DetIdStrAdaptor.detIdStr(), ntupleDataFormat.TrackingNtuple.getEvent(), ntupleDataFormat._RecoHitAdaptor.gluedHits(), ntupleDataFormat.Event.gluedHits(), ntupleDataFormat.TrackingNtuple.hasHits(), ntupleDataFormat.TrackingNtuple.hasSeeds(), ntupleDataFormat._RecoHitAdaptor.hits(), ntupleDataFormat.Seed.indexWithinAlgo(), ntupleDataFormat._RecoHitAdaptor.invalidHits(), ntupleDataFormat.TrackingParticle.isLooper(), ntupleDataFormat._DetIdStrAdaptor.layerStr(), ntupleDataFormat.TrackingParticle.matchedSeedInfos(), ntupleDataFormat._SimHitMatchAdaptor.matchedSimHitInfos(), ntupleDataFormat.TrackingParticle.matchedTrackInfos(), ntupleDataFormat._TrackingParticleMatchAdaptor.matchedTrackingParticleInfos(), ntupleDataFormat.GluedHit.monoHit(), ntupleDataFormat._HitObject.nseeds(), ntupleDataFormat.Seeds.nSeedsForAlgo(), ntupleDataFormat._HitObject.ntracks(), ntupleDataFormat.TrackingParticle.parentVertex(), ntupleDataFormat._RecoHitAdaptor.phase2OTHits(), ntupleDataFormat.Event.phase2OTHits(), ntupleDataFormat._RecoHitAdaptor.pixelHits(), ntupleDataFormat.Event.pixelHits(), ntupleDataFormat.SeedMatchInfo.seed(), ntupleDataFormat.Track.seed(), ntupleDataFormat.Seeds.seedForAlgo(), ntupleDataFormat._HitObject.seeds(), ntupleDataFormat.Event.seeds(), ntupleDataFormat.GluedHit.seeds(), ntupleDataFormat.Seeds.seedsForAlgo(), ntupleDataFormat.SimHitMatchInfo.simHit(), ntupleDataFormat.TrackingParticle.simHits(), ntupleDataFormat._Collection.size(), ntupleDataFormat.TrackingVertex.sourceTrackingParticles(), ntupleDataFormat.GluedHit.stereoHit(), ntupleDataFormat._RecoHitAdaptor.stripHits(), ntupleDataFormat.Event.stripHits(), ntupleDataFormat.TrackMatchInfo.track(), ntupleDataFormat.Seed.track(), ntupleDataFormat.TrackingParticleMatchInfo.trackingParticle(), ntupleDataFormat.SimHit.trackingParticle(), ntupleDataFormat.Event.trackingParticles(), ntupleDataFormat.Event.trackingVertices(), ntupleDataFormat._HitObject.tracks(), ntupleDataFormat.Event.tracks(), ntupleDataFormat.Vertex.tracks(), ntupleDataFormat.TrackingNtuple.tree(), ntupleDataFormat.Track.vertex(), and ntupleDataFormat.Event.vertices().