Logo ROOT  
Reference Guide
 
Loading...
Searching...
No Matches
RPageStorage.hxx
Go to the documentation of this file.
1/// \file ROOT/RPageStorage.hxx
2/// \ingroup NTuple
3/// \author Jakob Blomer <jblomer@cern.ch>
4/// \date 2018-07-19
5
6/*************************************************************************
7 * Copyright (C) 1995-2019, Rene Brun and Fons Rademakers. *
8 * All rights reserved. *
9 * *
10 * For the licensing terms see $ROOTSYS/LICENSE. *
11 * For the list of contributors see $ROOTSYS/README/CREDITS. *
12 *************************************************************************/
13
14#ifndef ROOT_RPageStorage
15#define ROOT_RPageStorage
16
17#include <ROOT/RError.hxx>
18#include <ROOT/RCluster.hxx>
25#include <ROOT/RNTupleUtil.hxx>
26#include <ROOT/RPage.hxx>
27#include <ROOT/RPagePool.hxx>
28#include <ROOT/RSpan.hxx>
29#include <string_view>
30
31#include <atomic>
32#include <cassert>
33#include <cstddef>
34#include <deque>
35#include <functional>
36#include <map>
37#include <memory>
38#include <mutex>
39#include <set>
40#include <shared_mutex>
41#include <unordered_map>
42#include <unordered_set>
43#include <vector>
44
45namespace ROOT {
46
47class RNTupleModel;
48
49namespace Internal {
50
51class RPageAllocator;
52class RColumn;
53struct RNTupleModelChangeset;
54
55enum class EPageStorageType {
56 kSink,
57 kSource,
58};
59
60// clang-format off
61/**
62\class ROOT::Internal::RPageStorage
63\ingroup NTuple
64\brief Common functionality of an ntuple storage for both reading and writing
65
66The RPageStore provides access to a storage container that keeps the bits of pages and clusters comprising
67an ntuple. Concrete implementations can use a TFile, a raw file, an object store, and so on.
68*/
69// clang-format on
71public:
72 /// The page checksum is a 64bit xxhash3
73 static constexpr std::size_t kNBytesPageChecksum = sizeof(std::uint64_t);
74
75 /// The interface of a task scheduler to schedule page (de)compression tasks
77 public:
78 virtual ~RTaskScheduler() = default;
79 /// Take a callable that represents a task
80 virtual void AddTask(const std::function<void(void)> &taskFunc) = 0;
81 /// Blocks until all scheduled tasks finished
82 virtual void Wait() = 0;
83 };
84
85 /// A sealed page contains the bytes of a page as written to storage (packed & compressed). It is used
86 /// as an input to UnsealPages() as well as to transfer pages between different storage media.
87 /// RSealedPage does _not_ own the buffer it is pointing to in order to not interfere with the memory management
88 /// of concrete page sink and page source implementations.
89 struct RSealedPage {
90 private:
91 const void *fBuffer = nullptr;
92 std::size_t fBufferSize = 0; ///< Size of the page payload and the trailing checksum (if available)
93 std::uint32_t fNElements = 0;
94 bool fHasChecksum = false; ///< If set, the last 8 bytes of the buffer are the xxhash of the rest of the buffer
95
96 public:
97 RSealedPage() = default;
98 RSealedPage(const void *buffer, std::size_t bufferSize, std::uint32_t nElements, bool hasChecksum = false)
100 {
101 }
102 RSealedPage(const RSealedPage &other) = default;
106
107 const void *GetBuffer() const { return fBuffer; }
108 void SetBuffer(const void *buffer) { fBuffer = buffer; }
109
115 std::size_t GetBufferSize() const { return fBufferSize; }
116 void SetBufferSize(std::size_t bufferSize) { fBufferSize = bufferSize; }
117
118 std::uint32_t GetNElements() const { return fNElements; }
119 void SetNElements(std::uint32_t nElements) { fNElements = nElements; }
120
121 bool GetHasChecksum() const { return fHasChecksum; }
123
124 void ChecksumIfEnabled();
126 /// Returns a failure if the sealed page has no checksum
128 };
129
130 using SealedPageSequence_t = std::deque<RSealedPage>;
131 /// A range of sealed pages referring to the same column that can be used for vector commit
134 SealedPageSequence_t::const_iterator fFirst;
135 SealedPageSequence_t::const_iterator fLast;
136
137 RSealedPageGroup() = default;
138 RSealedPageGroup(ROOT::DescriptorId_t d, SealedPageSequence_t::const_iterator b,
139 SealedPageSequence_t::const_iterator e)
141 {
142 }
143 };
144
145protected:
147
148 /// For the time being, we will use the heap allocator for all sources and sinks. This may change in the future.
149 std::unique_ptr<ROOT::Internal::RPageAllocator> fPageAllocator;
150
151 std::string fNTupleName;
154 {
155 if (!fTaskScheduler)
156 return;
158 }
159
160public:
161 explicit RPageStorage(std::string_view name);
166 virtual ~RPageStorage();
167
168 /// Whether the concrete implementation is a sink or a source
170
174
175 /// Returns true for a valid column handle; fColumn and fPhysicalId should always either both
176 /// be valid or both be invalid.
177 explicit operator bool() const { return fPhysicalId != ROOT::kInvalidDescriptorId && fColumn; }
178 };
179 /// The column handle identifies a column with the current open page storage
181
182 /// Register a new column. When reading, the column must exist in the ntuple on disk corresponding to the metadata.
183 /// When writing, every column can only be attached once.
185 /// Unregisters a column. A page source decreases the reference counter for the corresponding active column.
186 /// For a page sink, dropping columns is currently a no-op.
189
190 /// Returns the default metrics object. Subclasses might alternatively provide their own metrics object by
191 /// overriding this.
193
194 /// Returns the NTuple name.
195 const std::string &GetNTupleName() const { return fNTupleName; }
196
198}; // class RPageStorage
199
200// clang-format off
201/**
202\class ROOT::Internal::RWritePageMemoryManager
203\ingroup NTuple
204\brief Helper to maintain a memory budget for the write pages of a set of columns
205
206The memory manager keeps track of the sum of bytes used by the write pages of a set of columns.
207It will flush (and shrink) large pages of other columns on the attempt to expand a page.
208*/
209// clang-format on
211private:
212 struct RColumnInfo {
214 std::size_t fCurrentPageSize = 0;
215 std::size_t fInitialPageSize = 0;
216
217 bool operator>(const RColumnInfo &other) const;
218 };
219
220 /// Sum of all the write page sizes (their capacity) of the columns in `fColumnsSortedByPageSize`
221 std::size_t fCurrentAllocatedBytes = 0;
222 /// Maximum allowed value for `fCurrentAllocatedBytes`, set from RNTupleWriteOptions::fPageBufferBudget
223 std::size_t fMaxAllocatedBytes = 0;
224 /// All columns that called `ReservePage()` (hence `TryUpdate()`) at least once,
225 /// sorted by their current write page size from large to small
226 std::set<RColumnInfo, std::greater<RColumnInfo>> fColumnsSortedByPageSize;
227
228 /// Flush columns in order of allocated write page size until the sum of all write page allocations
229 /// leaves space for at least targetAvailableSize bytes. Only use columns with a write page size larger
230 /// than pageSizeLimit.
231 bool TryEvict(std::size_t targetAvailableSize, std::size_t pageSizeLimit);
232
233public:
235
236 /// Try to register the new write page size for the given column. Flush large columns to make space, if necessary.
237 /// If not enough space is available after all (sum of write pages would be larger than fMaxAllocatedBytes),
238 /// return false.
239 bool TryUpdate(ROOT::Internal::RColumn &column, std::size_t newWritePageSize);
240};
241
242// clang-format off
243/**
244\class ROOT::Internal::RPageSink
245\ingroup NTuple
246\brief Abstract interface to write data into an ntuple
247
248The page sink takes the list of columns and afterwards a series of page commits and cluster commits.
249The user is responsible to commit clusters at a consistent point, i.e. when all pages corresponding to data
250up to the given entry number are committed.
251
252An object of this class may either be a wrapper (for example a RPageSinkBuf) or a "persistent" sink,
253inheriting from RPagePersistentSink.
254*/
255// clang-format on
256class RPageSink : public RPageStorage {
257public:
258 using Callback_t = std::function<void(RPageSink &)>;
259
260 /// Cluster that was staged, but not yet logically appended to the RNTuple
274
275protected:
276 std::unique_ptr<ROOT::RNTupleWriteOptions> fOptions;
277
278 /// Flag if sink was initialized
279 bool fIsInitialized = false;
280
281 /// Helper for streaming a page. This is commonly used in derived, concrete page sinks. Note that if
282 /// compressionSetting is 0 (uncompressed) and the page is mappable and not checksummed, the returned sealed page
283 /// will point directly to the input page buffer. Otherwise, the sealed page references fSealPageBuffer. Thus,
284 /// the buffer pointed to by the RSealedPage should never be freed.
286
287private:
288 std::vector<Callback_t> fOnDatasetCommitCallbacks;
289 std::vector<unsigned char> fSealPageBuffer; ///< Used as destination buffer in the simple SealPage overload
290
291 /// Used in ReservePage to maintain the page buffer budget
293
294public:
295 RPageSink(std::string_view ntupleName, const ROOT::RNTupleWriteOptions &options);
296
297 RPageSink(const RPageSink &) = delete;
298 RPageSink &operator=(const RPageSink &) = delete;
299 RPageSink(RPageSink &&) = default;
301 ~RPageSink() override;
302
304 /// Returns the sink's write options.
306
307 void DropColumn(ColumnHandle_t /*columnHandle*/) final {}
308
309 bool IsInitialized() const { return fIsInitialized; }
310
311 /// Return the RNTupleDescriptor being constructed.
312 virtual const ROOT::RNTupleDescriptor &GetDescriptor() const = 0;
313
314 virtual ROOT::NTupleSize_t GetNEntries() const = 0;
315
316 /// Physically creates the storage container to hold the ntuple (e.g., a keys a TFile or an S3 bucket)
317 /// Init() associates column handles to the columns referenced by the model
318 void Init(RNTupleModel &model)
319 {
320 if (fIsInitialized) {
321 throw RException(R__FAIL("already initialized"));
322 }
323 fIsInitialized = true;
324 InitImpl(model);
325 }
326
327protected:
328 virtual void InitImpl(RNTupleModel &model) = 0;
329 virtual void CommitDatasetImpl() = 0;
330
331public:
332 /// Parameters for the SealPage() method
334 const ROOT::Internal::RPage *fPage = nullptr; ///< Input page to be sealed
336 nullptr; ///< Corresponds to the page's elements, for size calculation etc.
337 std::uint32_t fCompressionSettings = 0; ///< Compression algorithm and level to apply
338 /// Adds a 8 byte little-endian xxhash3 checksum to the page payload. The buffer has to be large enough to
339 /// to store the additional 8 bytes.
340 bool fWriteChecksum = true;
341 /// If false, the output buffer must not point to the input page buffer, which would otherwise be an option
342 /// if the page is mappable and should not be compressed
343 bool fAllowAlias = false;
344 /// Location for sealed output. The memory buffer has to be large enough.
345 void *fBuffer = nullptr;
346 };
347
348 /// Seal a page using the provided info.
349 static RSealedPage SealPage(const RSealPageConfig &config);
350
351 /// Incorporate incremental changes to the model into the ntuple descriptor. This happens, e.g. if new fields were
352 /// added after the initial call to `RPageSink::Init(RNTupleModel &)`.
353 /// `firstEntry` specifies the global index for the first stored element in the added columns.
355 /// Adds an extra type information record to schema. The extra type information will be written to the
356 /// extension header. The information in the record will be merged with the existing information, e.g.
357 /// duplicate streamer info records will be removed. This method is called by the "on commit dataset" callback
358 /// registered by specific fields (e.g., streamer field) and during merging.
360
361 /// Commits a suppressed column for the current cluster. Can be called anytime before CommitCluster().
362 /// For any given column and cluster, there must be no calls to both CommitSuppressedColumn() and page commits.
364 /// Write a page to the storage. The column must have been added before.
366 /// Write a preprocessed page to storage. The column must have been added before.
367 virtual void
369 /// Write a vector of preprocessed pages to storage. The corresponding columns must have been added before.
370 virtual void CommitSealedPageV(std::span<RPageStorage::RSealedPageGroup> ranges) = 0;
371 /// Stage the current cluster and create a new one for the following data.
372 /// Returns the object that must be passed to CommitStagedClusters to logically append the staged cluster to the
373 /// ntuple descriptor.
375 /// Commit staged clusters, logically appending them to the ntuple descriptor.
376 virtual void CommitStagedClusters(std::span<RStagedCluster> clusters) = 0;
377 /// Finalize the current cluster and create a new one for the following data.
378 /// Returns the number of bytes written to storage (excluding metadata).
385 /// Write out the page locations (page list envelope) for all the committed clusters since the last call of
386 /// CommitClusterGroup (or the beginning of writing).
387 virtual void CommitClusterGroup() = 0;
388
389 /// The registered callback is executed at the beginning of CommitDataset();
391 /// Run the registered callbacks and finalize the current cluster and the entrire data set.
392 void CommitDataset();
393
394 /// Get a new, empty page for the given column that can be filled with up to nElements;
395 /// nElements must be larger than zero.
397
398 /// An RAII wrapper used to synchronize a page sink. See GetSinkGuard().
400 std::mutex *fLock;
401
402 public:
403 explicit RSinkGuard(std::mutex *lock) : fLock(lock)
404 {
405 if (fLock != nullptr) {
406 fLock->lock();
407 }
408 }
409 RSinkGuard(const RSinkGuard &) = delete;
410 RSinkGuard &operator=(const RSinkGuard &) = delete;
411 RSinkGuard(RSinkGuard &&) = delete;
414 {
415 if (fLock != nullptr) {
416 fLock->unlock();
417 }
418 }
419 };
420
422 {
423 // By default, there is no lock and the guard does nothing.
424 return RSinkGuard(nullptr);
425 }
426}; // class RPageSink
427
428// clang-format off
429/**
430\class ROOT::Internal::RPagePersistentSink
431\ingroup NTuple
432\brief Base class for a sink with a physical storage backend
433*/
434// clang-format on
436private:
437 /// Used to map the IDs of the descriptor to the physical IDs issued during header/footer serialization
439
440 /// Remembers the starting cluster id for the next cluster group
441 std::uint64_t fNextClusterInGroup = 0;
442 /// Used to calculate the number of entries in the current cluster
444 /// Keeps track of the number of elements in the currently open cluster. Indexed by column id.
445 std::vector<ROOT::RClusterDescriptor::RColumnRange> fOpenColumnRanges;
446 /// Keeps track of the written pages in the currently open cluster. Indexed by column id.
447 std::vector<ROOT::RClusterDescriptor::RPageRange> fOpenPageRanges;
448
449 /// Union of the streamer info records that are sent from streamer fields to the sink before committing the dataset.
451
452protected:
453 /// Set of optional features supported by the persistent sink
454 struct RFeatures {
455 bool fCanMergePages = false;
456 };
457
460
461 /// Default I/O performance counters that get registered in fMetrics
471 std::unique_ptr<RCounters> fCounters;
472
473 virtual void InitImpl(unsigned char *serializedHeader, std::uint32_t length) = 0;
474
476 virtual RNTupleLocator
478 /// Vector commit of preprocessed pages. The `ranges` array specifies a range of sealed pages to be
479 /// committed for each column. The returned vector contains, in order, the RNTupleLocator for each
480 /// page on each range in `ranges`, i.e. the first N entries refer to the N pages in `ranges[0]`,
481 /// followed by M entries that refer to the M pages in `ranges[1]`, etc.
482 /// The mask allows to skip writing out certain pages. The vector has the size of all the pages.
483 /// For every `false` value in the mask, the corresponding locator is skipped (missing) in the output vector.
484 /// The default is to call `CommitSealedPageImpl` for each page; derived classes may provide an
485 /// optimized implementation though.
486 virtual std::vector<RNTupleLocator>
487 CommitSealedPageVImpl(std::span<RPageStorage::RSealedPageGroup> ranges, const std::vector<bool> &mask);
488 /// Returns the number of bytes written to storage (excluding metadata)
489 virtual std::uint64_t StageClusterImpl() = 0;
490 /// Returns the locator of the page list envelope of the given buffer that contains the serialized page list.
491 /// Typically, the implementation takes care of compressing and writing the provided buffer.
492 virtual RNTupleLocator CommitClusterGroupImpl(unsigned char *serializedPageList, std::uint32_t length) = 0;
493 virtual void CommitDatasetImpl(unsigned char *serializedFooter, std::uint32_t length) = 0;
494
495 /// Enables the default set of metrics provided by RPageSink. `prefix` will be used as the prefix for
496 /// the counters registered in the internal RNTupleMetrics object.
497 /// This set of counters can be extended by a subclass by calling `fMetrics.MakeCounter<...>()`.
498 ///
499 /// A subclass using the default set of metrics is always responsible for updating the counters
500 /// appropriately, e.g. `fCounters->fNPageCommited.Inc()`
501 void EnableDefaultMetrics(const std::string &prefix);
502
503public:
504 RPagePersistentSink(std::string_view ntupleName, const ROOT::RNTupleWriteOptions &options);
505
510 ~RPagePersistentSink() override;
511
512 /// Guess the concrete derived page source from the location
513 static std::unique_ptr<RPageSink> Create(std::string_view ntupleName, std::string_view location,
515
517
519
521
522 /// Updates the descriptor and calls InitImpl() that handles the backend-specific details (file, DAOS, etc.)
523 void InitImpl(RNTupleModel &model) final;
526
527 /// Initialize sink based on an existing descriptor and fill into the descriptor builder, optionally copying over
528 /// the descriptor's clusters to this sink's descriptor.
529 /// \return The model created from the new sink's descriptor. This model should be kept alive
530 /// for at least as long as the sink.
531 [[nodiscard]] std::unique_ptr<RNTupleModel>
533
537 void CommitSealedPageV(std::span<RPageStorage::RSealedPageGroup> ranges) final;
538 RStagedCluster StageCluster(ROOT::NTupleSize_t nNewEntries) final;
539 void CommitStagedClusters(std::span<RStagedCluster> clusters) final;
542}; // class RPagePersistentSink
543
544// clang-format off
545/**
546\class ROOT::Internal::RPageSource
547\ingroup NTuple
548\brief Abstract interface to read data from an ntuple
549
550The page source is initialized with the columns of interest. Alias columns from projected fields are mapped to the
551corresponding physical columns. Pages from the columns of interest can then be mapped into memory.
552The page source also gives access to the ntuple's metadata.
553*/
554// clang-format on
556public:
557 /// Used in SetEntryRange / GetEntryRange
558 struct REntryRange {
560 ROOT::NTupleSize_t fNEntries = 0;
561
562 /// Returns true if the given cluster has entries within the entry range
563 bool IntersectsWith(const ROOT::RClusterDescriptor &clusterDesc) const;
564 };
565
566 /// An RAII wrapper used for the read-only access to `RPageSource::fDescriptor`. See `GetExclDescriptorGuard()``.
569 std::shared_mutex &fLock;
570
571 public:
572 RSharedDescriptorGuard(const ROOT::RNTupleDescriptor &desc, std::shared_mutex &lock)
573 : fDescriptor(desc), fLock(lock)
574 {
575 fLock.lock_shared();
576 }
581 ~RSharedDescriptorGuard() { fLock.unlock_shared(); }
582 const ROOT::RNTupleDescriptor *operator->() const { return &fDescriptor; }
583 const ROOT::RNTupleDescriptor &GetRef() const { return fDescriptor; }
584 };
585
586 /// An RAII wrapper used for the writable access to `RPageSource::fDescriptor`. See `GetSharedDescriptorGuard()`.
589 std::shared_mutex &fLock;
590
591 public:
592 RExclDescriptorGuard(ROOT::RNTupleDescriptor &desc, std::shared_mutex &lock) : fDescriptor(desc), fLock(lock)
593 {
594 fLock.lock();
595 }
601 {
602 fDescriptor.IncGeneration();
603 fLock.unlock();
604 }
605 ROOT::RNTupleDescriptor *operator->() const { return &fDescriptor; }
606 void MoveIn(ROOT::RNTupleDescriptor desc) { fDescriptor = std::move(desc); }
607 };
608
609private:
611 mutable std::shared_mutex fDescriptorLock;
612 REntryRange fEntryRange; ///< Used by the cluster pool to prevent reading beyond the given range
613 bool fHasStructure = false; ///< Set to true once `LoadStructure()` is called
614 bool fIsAttached = false; ///< Set to true once `Attach()` is called
615
616 /// Remembers the last cluster id from which a page was requested
618 /// Clusters from where pages got preloaded in UnzipClusterImpl(), ordered by first entry number
619 /// of the clusters. If the last used cluster changes in LoadPage(), all unused pages from
620 /// previous clusters are evicted from the page pool.
621 std::map<ROOT::NTupleSize_t, ROOT::DescriptorId_t> fPreloadedClusters;
622
623 /// Does nothing if fLastUsedCluster == clusterId. Otherwise, updated fLastUsedCluster
624 /// and evict unused paged from the page pool of all previous clusters.
625 /// Must not be called when the descriptor guard is taken.
626 void UpdateLastUsedCluster(ROOT::DescriptorId_t clusterId);
627
628protected:
629 /// Default I/O performance counters that get registered in `fMetrics`
649
650 /// Keeps track of the requested physical column IDs and their in-memory target type via a column element identifier.
651 /// When using alias columns (projected fields), physical columns may be requested multiple times.
653 public:
658
659 private:
660 /// Maps physical column IDs to all the requested in-memory representations.
661 /// A pair of physical column ID and in-memory representation can be requested multiple times, which is
662 /// indicated by the reference counter.
663 /// We can only have a handful of possible in-memory representations for a given column,
664 /// so it is fine to search them linearly.
665 std::unordered_map<ROOT::DescriptorId_t, std::vector<RColumnInfo>> fColumnInfos;
666
667 public:
672 {
673 return fColumnInfos.count(physicalColumnId) > 0;
674 }
675 const std::vector<RColumnInfo> &GetColumnInfos(ROOT::DescriptorId_t physicalColumnId) const
676 {
677 return fColumnInfos.at(physicalColumnId);
678 }
679 };
680
681 /// Summarizes cluster-level information that are necessary to load a certain page.
682 /// Used by LoadPageImpl().
684 ROOT::DescriptorId_t fClusterId = 0;
685 /// Location of the page on disk
687 /// The first element number of the page's column in the given cluster
688 std::uint64_t fColumnOffset = 0;
689 };
690
691 std::unique_ptr<RCounters> fCounters;
692
694 /// The active columns are implicitly defined by the model fields or views
696
697 /// Pages that are unzipped with IMT are staged into the page pool
699
700 virtual void LoadStructureImpl() = 0;
701 /// `LoadStructureImpl()` has been called before `AttachImpl()` is called
703 /// Returns a new, unattached page source for the same data set
704 virtual std::unique_ptr<RPageSource> CloneImpl() const = 0;
705 // Only called if a task scheduler is set. No-op be default.
706 virtual void UnzipClusterImpl(ROOT::Experimental::Internal::RCluster *cluster);
707 // Returns a page from storage if not found in the page pool. Should be able to handle zero page locators.
710
711 /// Prepare a page range read for the column set in `clusterKey`. Specifically, pages referencing the
712 /// `kTypePageZero` locator are filled in `pageZeroMap`; otherwise, `perPageFunc` is called for each page. This is
713 /// commonly used as part of `LoadClusters()` in derived classes.
714 void PrepareLoadCluster(
719
720 /// Enables the default set of metrics provided by RPageSource. `prefix` will be used as the prefix for
721 /// the counters registered in the internal RNTupleMetrics object.
722 /// A subclass using the default set of metrics is responsible for updating the counters
723 /// appropriately, e.g. `fCounters->fNRead.Inc()`
724 /// Alternatively, a subclass might provide its own RNTupleMetrics object by overriding the
725 /// `GetMetrics()` member function.
726 void EnableDefaultMetrics(const std::string &prefix);
727
728 /// Note that the underlying lock is not recursive. See `GetSharedDescriptorGuard()` for further information.
729 RExclDescriptorGuard GetExclDescriptorGuard() { return RExclDescriptorGuard(fDescriptor, fDescriptorLock); }
730
731public:
733 RPageSource(const RPageSource &) = delete;
737 ~RPageSource() override;
738 /// Guess the concrete derived page source from the file name (location)
739 static std::unique_ptr<RPageSource> Create(std::string_view ntupleName, std::string_view location,
741 /// Open the same storage multiple time, e.g. for reading in multiple threads.
742 /// If the source is already attached, the clone will be attached, too. The clone will use, however,
743 /// it's own connection to the underlying storage (e.g., file descriptor, XRootD handle, etc.)
744 std::unique_ptr<RPageSource> Clone() const;
745
746 /// Helper for unstreaming a page. This is commonly used in derived, concrete page sources. The implementation
747 /// currently always makes a memory copy, even if the sealed page is uncompressed and in the final memory layout.
748 /// The optimization of directly mapping pages is left to the concrete page source implementations.
752
755
756 /// Takes the read lock for the descriptor. Multiple threads can take the lock concurrently.
757 /// The underlying `std::shared_mutex`, however, is neither read nor write recursive:
758 /// within one thread, only one lock (shared or exclusive) must be acquired at the same time. This requires special
759 /// care in sections protected by `GetSharedDescriptorGuard()` and `GetExclDescriptorGuard()` especially to avoid
760 /// that the locks are acquired indirectly (e.g. by a call to `GetNEntries()`). As a general guideline, no other
761 /// method of the page source should be called (directly or indirectly) in a guarded section.
763 {
764 return RSharedDescriptorGuard(fDescriptor, fDescriptorLock);
765 }
766
769
770 /// Loads header and footer without decompressing or deserializing them. This can be used to asynchronously open
771 /// a file in the background. The method is idempotent and it is called as a first step in `Attach()`.
772 /// Pages sources may or may not make use of splitting loading and processing metadata.
773 /// Therefore, `LoadStructure()` may do nothing and defer loading the metadata to `Attach()`.
774 void LoadStructure();
775 /// Open the physical storage container and deserialize header and footer
780
781 /// Promise to only read from the given entry range. If set, prevents the cluster pool from reading-ahead beyond
782 /// the given range. The range needs to be within `[0, GetNEntries())`.
783 void SetEntryRange(const REntryRange &range);
784 REntryRange GetEntryRange() const { return fEntryRange; }
785
786 /// Allocates and fills a page that contains the index-th element. The default implementation searches
787 /// the page and calls LoadPageImpl(). Returns a default-constructed RPage for suppressed columns.
789 /// Another version of `LoadPage` that allows to specify cluster-relative indexes.
790 /// Returns a default-constructed RPage for suppressed columns.
792
793 /// Read the packed and compressed bytes of a page into the memory buffer provided by `sealedPage`. The sealed page
794 /// can be used subsequently in a call to `RPageSink::CommitSealedPage`.
795 /// The `fSize` and `fNElements` member of the sealedPage parameters are always set. If `sealedPage.fBuffer` is
796 /// `nullptr`, no data will be copied but the returned size information can be used by the caller to allocate a large
797 /// enough buffer and call `LoadSealedPage` again.
798 virtual void
800
801 /// Populates all the pages of the given cluster ids and columns; it is possible that some columns do not
802 /// contain any pages. The page source may load more columns than the minimal necessary set from `columns`.
803 /// To indicate which columns have been loaded, `LoadClusters()`` must mark them with `SetColumnAvailable()`.
804 /// That includes the ones from the `columns` that don't have pages; otherwise subsequent requests
805 /// for the cluster would assume an incomplete cluster and trigger loading again.
806 /// `LoadClusters()` is typically called from the I/O thread of a cluster pool, i.e. the method runs
807 /// concurrently to other methods of the page source.
808 virtual std::vector<std::unique_ptr<ROOT::Experimental::Internal::RCluster>>
809 LoadClusters(std::span<ROOT::Experimental::Internal::RCluster::RKey> clusterKeys) = 0;
810
811 /// Parallel decompression and unpacking of the pages in the given cluster. The unzipped pages are supposed
812 /// to be preloaded in a page pool attached to the source. The method is triggered by the cluster pool's
813 /// unzip thread. It is an optional optimization, the method can safely do nothing. In particular, the
814 /// actual implementation will only run if a task scheduler is set. In practice, a task scheduler is set
815 /// if implicit multi-threading is turned on.
817
818 // TODO(gparolini): for symmetry with SealPage(), we should either make this private or SealPage() public.
821}; // class RPageSource
822
823} // namespace Internal
824} // namespace ROOT
825
826#endif
#define R__FAIL(msg)
Short-hand to return an RResult<T> in an error state; the RError is implicitly converted into RResult...
Definition RError.hxx:299
#define d(i)
Definition RSha256.hxx:102
#define b(i)
Definition RSha256.hxx:100
#define e(i)
Definition RSha256.hxx:103
ROOT::Detail::TRangeCast< T, true > TRangeDynCast
TRangeDynCast is an adapter class that allows the typed iteration through a TCollection.
Option_t Option_t TPoint TPoint const char GetTextMagnitude GetFillStyle GetLineColor GetLineWidth GetMarkerStyle GetTextAlign GetTextColor GetTextSize void char Point_t Rectangle_t WindowAttributes_t Float_t Float_t Float_t Int_t Int_t UInt_t UInt_t Rectangle_t mask
Option_t Option_t TPoint TPoint const char GetTextMagnitude GetFillStyle GetLineColor GetLineWidth GetMarkerStyle GetTextAlign GetTextColor GetTextSize void char Point_t Rectangle_t WindowAttributes_t Float_t Float_t Float_t Int_t Int_t UInt_t UInt_t Rectangle_t Int_t Int_t Window_t TString Int_t GCValues_t GetPrimarySelectionOwner GetDisplay GetScreen GetColormap GetNativeEvent const char const char dpyName wid window const char font_name cursor keysym reg const char only_if_exist regb h Point_t winding char text const char depth char const char Int_t count const char ColorStruct_t color const char Pixmap_t Pixmap_t PictureAttributes_t attr const char char ret_data h unsigned char height h length
Option_t Option_t TPoint TPoint const char mode
char name[80]
Definition TGX11.cxx:110
A thread-safe integral performance counter.
A metric element that computes its floating point value from other counters.
A collection of Counter objects with a name, a unit, and a description.
An in-memory subset of the packed and compressed pages of a cluster.
Definition RCluster.hxx:152
std::unordered_set< ROOT::DescriptorId_t > ColumnSet_t
Definition RCluster.hxx:154
A memory region that contains packed and compressed pages.
Definition RCluster.hxx:103
A column element encapsulates the translation between basic C++ types and their column representation...
A column is a storage-backed array of a simple, fixed-size type, from which pages can be mapped into ...
Definition RColumn.hxx:38
A helper class for piece-wise construction of an RNTupleDescriptor.
const RNTupleDescriptor & GetDescriptor() const
The serialization context is used for the piecewise serialization of a descriptor.
std::map< Int_t, TVirtualStreamerInfo * > StreamerInfoMap_t
@ kForReading
Deserializes the descriptor and performs fixup on the suppressed column ranges and on clusters,...
Abstract interface to allocate and release pages.
Base class for a sink with a physical storage backend.
RStagedCluster StageCluster(ROOT::NTupleSize_t nNewEntries) final
Stage the current cluster and create a new one for the following data.
void CommitSealedPage(ROOT::DescriptorId_t physicalColumnId, const RPageStorage::RSealedPage &sealedPage) final
Write a preprocessed page to storage. The column must have been added before.
RPagePersistentSink(RPagePersistentSink &&)=default
std::uint64_t fNextClusterInGroup
Remembers the starting cluster id for the next cluster group.
std::unique_ptr< RNTupleModel > InitFromDescriptor(const ROOT::RNTupleDescriptor &descriptor, bool copyClusters)
Initialize sink based on an existing descriptor and fill into the descriptor builder,...
void UpdateExtraTypeInfo(const ROOT::RExtraTypeInfoDescriptor &extraTypeInfo) final
Adds an extra type information record to schema.
ColumnHandle_t AddColumn(ROOT::DescriptorId_t fieldId, ROOT::Internal::RColumn &column) final
Register a new column.
ROOT::Internal::RNTupleDescriptorBuilder fDescriptorBuilder
RPagePersistentSink & operator=(RPagePersistentSink &&)=default
virtual std::vector< RNTupleLocator > CommitSealedPageVImpl(std::span< RPageStorage::RSealedPageGroup > ranges, const std::vector< bool > &mask)
Vector commit of preprocessed pages.
RPagePersistentSink(std::string_view ntupleName, const ROOT::RNTupleWriteOptions &options)
RPagePersistentSink & operator=(const RPagePersistentSink &)=delete
ROOT::NTupleSize_t GetNEntries() const final
RPagePersistentSink(const RPagePersistentSink &)=delete
void CommitSuppressedColumn(ColumnHandle_t columnHandle) final
Commits a suppressed column for the current cluster.
ROOT::Internal::RNTupleSerializer::RContext fSerializationContext
Used to map the IDs of the descriptor to the physical IDs issued during header/footer serialization.
ROOT::NTupleSize_t fPrevClusterNEntries
Used to calculate the number of entries in the current cluster.
void UpdateSchema(const ROOT::Internal::RNTupleModelChangeset &changeset, ROOT::NTupleSize_t firstEntry) final
Incorporate incremental changes to the model into the ntuple descriptor.
ROOT::Internal::RNTupleSerializer::StreamerInfoMap_t fStreamerInfos
Union of the streamer info records that are sent from streamer fields to the sink before committing t...
virtual RNTupleLocator CommitClusterGroupImpl(unsigned char *serializedPageList, std::uint32_t length)=0
Returns the locator of the page list envelope of the given buffer that contains the serialized page l...
void CommitStagedClusters(std::span< RStagedCluster > clusters) final
Commit staged clusters, logically appending them to the ntuple descriptor.
static std::unique_ptr< RPageSink > Create(std::string_view ntupleName, std::string_view location, const ROOT::RNTupleWriteOptions &options=ROOT::RNTupleWriteOptions())
Guess the concrete derived page source from the location.
std::vector< ROOT::RClusterDescriptor::RPageRange > fOpenPageRanges
Keeps track of the written pages in the currently open cluster. Indexed by column id.
void CommitPage(ColumnHandle_t columnHandle, const ROOT::Internal::RPage &page) final
Write a page to the storage. The column must have been added before.
virtual void InitImpl(unsigned char *serializedHeader, std::uint32_t length)=0
const ROOT::RNTupleDescriptor & GetDescriptor() const final
Return the RNTupleDescriptor being constructed.
virtual void CommitDatasetImpl(unsigned char *serializedFooter, std::uint32_t length)=0
std::vector< ROOT::RClusterDescriptor::RColumnRange > fOpenColumnRanges
Keeps track of the number of elements in the currently open cluster. Indexed by column id.
std::unique_ptr< RCounters > fCounters
void CommitClusterGroup() final
Write out the page locations (page list envelope) for all the committed clusters since the last call ...
virtual RNTupleLocator CommitSealedPageImpl(ROOT::DescriptorId_t physicalColumnId, const RPageStorage::RSealedPage &sealedPage)=0
void CommitSealedPageV(std::span< RPageStorage::RSealedPageGroup > ranges) final
Write a vector of preprocessed pages to storage. The corresponding columns must have been added befor...
void EnableDefaultMetrics(const std::string &prefix)
Enables the default set of metrics provided by RPageSink.
virtual RNTupleLocator CommitPageImpl(ColumnHandle_t columnHandle, const ROOT::Internal::RPage &page)=0
virtual std::uint64_t StageClusterImpl()=0
Returns the number of bytes written to storage (excluding metadata)
A thread-safe cache of pages loaded from the page source.
Definition RPagePool.hxx:44
Reference to a page stored in the page pool.
An RAII wrapper used to synchronize a page sink. See GetSinkGuard().
RSinkGuard & operator=(const RSinkGuard &)=delete
RSinkGuard & operator=(RSinkGuard &&)=delete
RSinkGuard(const RSinkGuard &)=delete
Abstract interface to write data into an ntuple.
RPageSink(RPageSink &&)=default
virtual void CommitSealedPage(ROOT::DescriptorId_t physicalColumnId, const RPageStorage::RSealedPage &sealedPage)=0
Write a preprocessed page to storage. The column must have been added before.
std::vector< unsigned char > fSealPageBuffer
Used as destination buffer in the simple SealPage overload.
virtual void CommitSuppressedColumn(ColumnHandle_t columnHandle)=0
Commits a suppressed column for the current cluster.
std::unique_ptr< ROOT::RNTupleWriteOptions > fOptions
void RegisterOnCommitDatasetCallback(Callback_t callback)
The registered callback is executed at the beginning of CommitDataset();.
std::vector< Callback_t > fOnDatasetCommitCallbacks
virtual ROOT::Internal::RPage ReservePage(ColumnHandle_t columnHandle, std::size_t nElements)
Get a new, empty page for the given column that can be filled with up to nElements; nElements must be...
const ROOT::RNTupleWriteOptions & GetWriteOptions() const
Returns the sink's write options.
virtual void CommitClusterGroup()=0
Write out the page locations (page list envelope) for all the committed clusters since the last call ...
virtual RStagedCluster StageCluster(ROOT::NTupleSize_t nNewEntries)=0
Stage the current cluster and create a new one for the following data.
virtual void CommitPage(ColumnHandle_t columnHandle, const ROOT::Internal::RPage &page)=0
Write a page to the storage. The column must have been added before.
RPageSink & operator=(const RPageSink &)=delete
EPageStorageType GetType() final
Whether the concrete implementation is a sink or a source.
void Init(RNTupleModel &model)
Physically creates the storage container to hold the ntuple (e.g., a keys a TFile or an S3 bucket) In...
virtual void UpdateExtraTypeInfo(const ROOT::RExtraTypeInfoDescriptor &extraTypeInfo)=0
Adds an extra type information record to schema.
RPageSink(const RPageSink &)=delete
virtual void CommitStagedClusters(std::span< RStagedCluster > clusters)=0
Commit staged clusters, logically appending them to the ntuple descriptor.
virtual std::uint64_t CommitCluster(ROOT::NTupleSize_t nNewEntries)
Finalize the current cluster and create a new one for the following data.
virtual void InitImpl(RNTupleModel &model)=0
virtual RSinkGuard GetSinkGuard()
std::function< void(RPageSink &)> Callback_t
virtual void UpdateSchema(const ROOT::Internal::RNTupleModelChangeset &changeset, ROOT::NTupleSize_t firstEntry)=0
Incorporate incremental changes to the model into the ntuple descriptor.
RSealedPage SealPage(const ROOT::Internal::RPage &page, const ROOT::Internal::RColumnElementBase &element)
Helper for streaming a page.
bool fIsInitialized
Flag if sink was initialized.
RPageSink(std::string_view ntupleName, const ROOT::RNTupleWriteOptions &options)
RPageSink & operator=(RPageSink &&)=default
virtual const ROOT::RNTupleDescriptor & GetDescriptor() const =0
Return the RNTupleDescriptor being constructed.
virtual void CommitSealedPageV(std::span< RPageStorage::RSealedPageGroup > ranges)=0
Write a vector of preprocessed pages to storage. The corresponding columns must have been added befor...
virtual ROOT::NTupleSize_t GetNEntries() const =0
void CommitDataset()
Run the registered callbacks and finalize the current cluster and the entrire data set.
RWritePageMemoryManager fWritePageMemoryManager
Used in ReservePage to maintain the page buffer budget.
virtual void CommitDatasetImpl()=0
void DropColumn(ColumnHandle_t) final
Unregisters a column.
Keeps track of the requested physical column IDs and their in-memory target type via a column element...
const std::vector< RColumnInfo > & GetColumnInfos(ROOT::DescriptorId_t physicalColumnId) const
std::unordered_map< ROOT::DescriptorId_t, std::vector< RColumnInfo > > fColumnInfos
Maps physical column IDs to all the requested in-memory representations.
bool HasColumnInfos(ROOT::DescriptorId_t physicalColumnId) const
An RAII wrapper used for the writable access to RPageSource::fDescriptor. See GetSharedDescriptorGuar...
void MoveIn(ROOT::RNTupleDescriptor desc)
RExclDescriptorGuard & operator=(const RExclDescriptorGuard &)=delete
ROOT::RNTupleDescriptor * operator->() const
RExclDescriptorGuard(RExclDescriptorGuard &&)=delete
RExclDescriptorGuard(ROOT::RNTupleDescriptor &desc, std::shared_mutex &lock)
RExclDescriptorGuard(const RExclDescriptorGuard &)=delete
RExclDescriptorGuard & operator=(RExclDescriptorGuard &&)=delete
An RAII wrapper used for the read-only access to RPageSource::fDescriptor. See GetExclDescriptorGuard...
RSharedDescriptorGuard(const RSharedDescriptorGuard &)=delete
RSharedDescriptorGuard(RSharedDescriptorGuard &&)=delete
const ROOT::RNTupleDescriptor & GetRef() const
RSharedDescriptorGuard & operator=(const RSharedDescriptorGuard &)=delete
const ROOT::RNTupleDescriptor * operator->() const
RSharedDescriptorGuard(const ROOT::RNTupleDescriptor &desc, std::shared_mutex &lock)
RSharedDescriptorGuard & operator=(RSharedDescriptorGuard &&)=delete
Abstract interface to read data from an ntuple.
RPageSource & operator=(RPageSource &&)=delete
EPageStorageType GetType() final
Whether the concrete implementation is a sink or a source.
RPageSource & operator=(const RPageSource &)=delete
RExclDescriptorGuard GetExclDescriptorGuard()
Note that the underlying lock is not recursive. See GetSharedDescriptorGuard() for further informatio...
ROOT::RNTupleReadOptions fOptions
REntryRange GetEntryRange() const
const RSharedDescriptorGuard GetSharedDescriptorGuard() const
Takes the read lock for the descriptor.
std::map< ROOT::NTupleSize_t, ROOT::DescriptorId_t > fPreloadedClusters
Clusters from where pages got preloaded in UnzipClusterImpl(), ordered by first entry number of the c...
REntryRange fEntryRange
Used by the cluster pool to prevent reading beyond the given range.
virtual ROOT::Internal::RPageRef LoadPageImpl(ColumnHandle_t columnHandle, const RClusterInfo &clusterInfo, ROOT::NTupleSize_t idxInCluster)=0
virtual std::unique_ptr< RPageSource > CloneImpl() const =0
Returns a new, unattached page source for the same data set.
std::unique_ptr< RCounters > fCounters
virtual void LoadStructureImpl()=0
ROOT::RNTupleDescriptor fDescriptor
ROOT::Internal::RPagePool fPagePool
Pages that are unzipped with IMT are staged into the page pool.
virtual ROOT::RNTupleDescriptor AttachImpl(ROOT::Internal::RNTupleSerializer::EDescriptorDeserializeMode mode)=0
LoadStructureImpl() has been called before AttachImpl() is called
std::shared_mutex fDescriptorLock
RPageSource(RPageSource &&)=delete
RPageSource(const RPageSource &)=delete
virtual std::vector< std::unique_ptr< ROOT::Experimental::Internal::RCluster > > LoadClusters(std::span< ROOT::Experimental::Internal::RCluster::RKey > clusterKeys)=0
Populates all the pages of the given cluster ids and columns; it is possible that some columns do not...
const ROOT::RNTupleReadOptions & GetReadOptions() const
RActivePhysicalColumns fActivePhysicalColumns
The active columns are implicitly defined by the model fields or views.
virtual void LoadSealedPage(ROOT::DescriptorId_t physicalColumnId, RNTupleLocalIndex localIndex, RSealedPage &sealedPage)=0
Read the packed and compressed bytes of a page into the memory buffer provided by sealedPage.
The interface of a task scheduler to schedule page (de)compression tasks.
virtual void Wait()=0
Blocks until all scheduled tasks finished.
virtual void AddTask(const std::function< void(void)> &taskFunc)=0
Take a callable that represents a task.
Common functionality of an ntuple storage for both reading and writing.
virtual ColumnHandle_t AddColumn(ROOT::DescriptorId_t fieldId, ROOT::Internal::RColumn &column)=0
Register a new column.
void SetTaskScheduler(RTaskScheduler *taskScheduler)
RPageStorage(const RPageStorage &other)=delete
virtual ROOT::Experimental::Detail::RNTupleMetrics & GetMetrics()
Returns the default metrics object.
RPageStorage & operator=(const RPageStorage &other)=delete
ROOT::DescriptorId_t GetColumnId(ColumnHandle_t columnHandle) const
virtual void DropColumn(ColumnHandle_t columnHandle)=0
Unregisters a column.
RPageStorage & operator=(RPageStorage &&other)=default
std::unique_ptr< ROOT::Internal::RPageAllocator > fPageAllocator
For the time being, we will use the heap allocator for all sources and sinks. This may change in the ...
static constexpr std::size_t kNBytesPageChecksum
The page checksum is a 64bit xxhash3.
std::deque< RSealedPage > SealedPageSequence_t
virtual EPageStorageType GetType()=0
Whether the concrete implementation is a sink or a source.
RColumnHandle ColumnHandle_t
The column handle identifies a column with the current open page storage.
RPageStorage(RPageStorage &&other)=default
ROOT::Experimental::Detail::RNTupleMetrics fMetrics
RPageStorage(std::string_view name)
const std::string & GetNTupleName() const
Returns the NTuple name.
A page is a slice of a column that is mapped into memory.
Definition RPage.hxx:44
Helper to maintain a memory budget for the write pages of a set of columns.
std::size_t fCurrentAllocatedBytes
Sum of all the write page sizes (their capacity) of the columns in fColumnsSortedByPageSize
std::size_t fMaxAllocatedBytes
Maximum allowed value for fCurrentAllocatedBytes, set from RNTupleWriteOptions::fPageBufferBudget.
bool TryEvict(std::size_t targetAvailableSize, std::size_t pageSizeLimit)
Flush columns in order of allocated write page size until the sum of all write page allocations leave...
bool TryUpdate(ROOT::Internal::RColumn &column, std::size_t newWritePageSize)
Try to register the new write page size for the given column.
RWritePageMemoryManager(std::size_t maxAllocatedBytes)
std::set< RColumnInfo, std::greater< RColumnInfo > > fColumnsSortedByPageSize
All columns that called ReservePage() (hence TryUpdate()) at least once, sorted by their current writ...
Records the partition of data into pages for a particular column in a particular cluster.
Metadata for RNTuple clusters.
Base class for all ROOT issued exceptions.
Definition RError.hxx:79
Field specific extra type information from the header / extenstion header.
The on-storage metadata of an RNTuple.
Addresses a column element or field item relative to a particular cluster, instead of a global NTuple...
Generic information about the physical location of data.
The RNTupleModel encapulates the schema of an RNTuple.
Common user-tunable settings for reading RNTuples.
Common user-tunable settings for storing RNTuples.
tbb::task_arena is an alias of tbb::interface7::task_arena, which doesn't allow to forward declare tb...
std::uint64_t DescriptorId_t
Distriniguishes elements of the same type within a descriptor, e.g. different fields.
constexpr NTupleSize_t kInvalidNTupleIndex
std::uint64_t NTupleSize_t
Integer type long enough to hold the maximum number of entries in a column.
constexpr DescriptorId_t kInvalidDescriptorId
The identifiers that specifies the content of a (partial) cluster.
Definition RCluster.hxx:156
Every concrete RColumnElement type is identified by its on-disk type (column type) and the in-memory ...
The incremental changes to a RNTupleModel
Default I/O performance counters that get registered in fMetrics.
ROOT::Experimental::Detail::RNTupleAtomicCounter & fSzWritePayload
ROOT::Experimental::Detail::RNTupleTickCounter< ROOT::Experimental::Detail::RNTupleAtomicCounter > & fTimeCpuWrite
ROOT::Experimental::Detail::RNTupleAtomicCounter & fTimeWallWrite
ROOT::Experimental::Detail::RNTupleTickCounter< ROOT::Experimental::Detail::RNTupleAtomicCounter > & fTimeCpuZip
ROOT::Experimental::Detail::RNTupleAtomicCounter & fTimeWallZip
ROOT::Experimental::Detail::RNTupleAtomicCounter & fSzZip
ROOT::Experimental::Detail::RNTupleAtomicCounter & fNPageCommitted
Set of optional features supported by the persistent sink.
Parameters for the SealPage() method.
bool fWriteChecksum
Adds a 8 byte little-endian xxhash3 checksum to the page payload.
std::uint32_t fCompressionSettings
Compression algorithm and level to apply.
void * fBuffer
Location for sealed output. The memory buffer has to be large enough.
const ROOT::Internal::RPage * fPage
Input page to be sealed.
bool fAllowAlias
If false, the output buffer must not point to the input page buffer, which would otherwise be an opti...
const ROOT::Internal::RColumnElementBase * fElement
Corresponds to the page's elements, for size calculation etc.
ROOT::RClusterDescriptor::RPageRange fPageRange
Cluster that was staged, but not yet logically appended to the RNTuple.
std::vector< RColumnInfo > fColumnInfos
ROOT::Internal::RColumnElementBase::RIdentifier fElementId
Summarizes cluster-level information that are necessary to load a certain page.
ROOT::RClusterDescriptor::RPageInfoExtended fPageInfo
Location of the page on disk.
Default I/O performance counters that get registered in fMetrics
ROOT::Experimental::Detail::RNTupleAtomicCounter & fNPageUnsealed
ROOT::Experimental::Detail::RNTupleAtomicCounter & fNRead
ROOT::Experimental::Detail::RNTupleAtomicCounter & fTimeWallRead
ROOT::Experimental::Detail::RNTupleAtomicCounter & fSzReadOverhead
ROOT::Experimental::Detail::RNTupleCalcPerf & fCompressionRatio
ROOT::Experimental::Detail::RNTupleCalcPerf & fFractionReadOverhead
ROOT::Experimental::Detail::RNTupleAtomicCounter & fNReadV
ROOT::Experimental::Detail::RNTupleAtomicCounter & fNClusterLoaded
ROOT::Experimental::Detail::RNTupleAtomicCounter & fTimeWallUnzip
ROOT::Experimental::Detail::RNTupleAtomicCounter & fNPageRead
ROOT::Experimental::Detail::RNTupleAtomicCounter & fSzReadPayload
ROOT::Experimental::Detail::RNTupleCalcPerf & fBandwidthReadCompressed
ROOT::Experimental::Detail::RNTupleTickCounter< ROOT::Experimental::Detail::RNTupleAtomicCounter > & fTimeCpuUnzip
ROOT::Experimental::Detail::RNTupleTickCounter< ROOT::Experimental::Detail::RNTupleAtomicCounter > & fTimeCpuRead
ROOT::Experimental::Detail::RNTupleCalcPerf & fBandwidthReadUncompressed
ROOT::Experimental::Detail::RNTupleCalcPerf & fBandwidthUnzip
ROOT::Experimental::Detail::RNTupleAtomicCounter & fSzUnzip
Used in SetEntryRange / GetEntryRange.
A range of sealed pages referring to the same column that can be used for vector commit.
SealedPageSequence_t::const_iterator fFirst
SealedPageSequence_t::const_iterator fLast
RSealedPageGroup(ROOT::DescriptorId_t d, SealedPageSequence_t::const_iterator b, SealedPageSequence_t::const_iterator e)
A sealed page contains the bytes of a page as written to storage (packed & compressed).
RSealedPage(const void *buffer, std::size_t bufferSize, std::uint32_t nElements, bool hasChecksum=false)
RResult< void > VerifyChecksumIfEnabled() const
RSealedPage(const RSealedPage &other)=default
bool fHasChecksum
If set, the last 8 bytes of the buffer are the xxhash of the rest of the buffer.
RSealedPage & operator=(RSealedPage &&other)=default
void SetNElements(std::uint32_t nElements)
RSealedPage(RSealedPage &&other)=default
RResult< std::uint64_t > GetChecksum() const
Returns a failure if the sealed page has no checksum.
RSealedPage & operator=(const RSealedPage &other)=default
void SetBufferSize(std::size_t bufferSize)
std::size_t fBufferSize
Size of the page payload and the trailing checksum (if available)
bool operator>(const RColumnInfo &other) const
Additional information about a page in an in-memory RPageRange.
Information about a single page in the context of a cluster's page range.