db.hpp 38 KB

123456789101112131415161718192021222324252627282930313233343536373839404142434445464748495051525354555657585960616263646566676869707172737475767778798081828384858687888990919293949596979899100101102103104105106107108109110111112113114115116117118119120121122123124125126127128129130131132133134135136137138139140141142143144145146147148149150151152153154155156157158159160161162163164165166167168169170171172173174175176177178179180181182183184185186187188189190191192193194195196197198199200201202203204205206207208209210211212213214215216217218219220221222223224225226227228229230231232233234235236237238239240241242243244245246247248249250251252253254255256257258259260261262263264265266267268269270271272273274275276277278279280281282283284285286287288289290291292293294295296297298299300301302303304305306307308309310311312313314315316317318319320321322323324325326327328329330331332333334335336337338339340341342343344345346347348349350351352353354355356357358359360361362363364365366367368369370371372373374375376377378379380381382383384385386387388389390391392393394395396397398399400401402403404405406407408409410411412413414415416417418419420421422423424425426427428429430431432433434435436437438439440441442443444445446447448449450451452453454455456457458459460461462463464465466467468469470471472473474475476477478479480481482483484485486487488489490491492493494495496497498499500501502503504505506507508509510511512513514515516517518519520521522523524525526527528529530531532533534535536537538539540541542543544545546547548549550551552553554555556557558559560561562563564565566567568569570571572573574575576577578579580581582583584585586587588589590591592593594595596597598599600601602603604605606607608609610611612613614615616617618619620621622623624625626627628629630631632633634635636637638639640641642643644645646647648649650651652653654655656657658659660661662663664665666667668669670671672673674675676677678679680681682683684685686687688689690691692693694695696697698699700701702703704705706707708709710711712713714715716717718719720721722723724725726727728729730731732733734735736737738739740741742743744745746747748749750751752753754755756757758759760761762763764765766767768769770771772773774775776777778779780781782783784785786787788789790791792793794795796797798799800801802803804805806807808809810811812813814815816817818819820821822823824825826827828829830831832833834835836837838839840841842843844845846847848849850851852853854855856857858859860861862863864865866867868869870871872873874875876877878879880881882883884885886887888889890891892893894895896897898899900901902903904905906907908909910911912913914915916917918919920921922923924925926927928929930931932933934935936937938939940941942943944945946947948949950951952953954955956957958959960961962963964965966967968969970971972973974975976977978979980981982983984985986987988989990991992993994995996997998999100010011002100310041005100610071008100910101011101210131014101510161017101810191020102110221023102410251026102710281029103010311032103310341035103610371038103910401041104210431044104510461047104810491050105110521053
  1. /*************************************************************************
  2. *
  3. * Copyright 2016 Realm Inc.
  4. *
  5. * Licensed under the Apache License, Version 2.0 (the "License");
  6. * you may not use this file except in compliance with the License.
  7. * You may obtain a copy of the License at
  8. *
  9. * http://www.apache.org/licenses/LICENSE-2.0
  10. *
  11. * Unless required by applicable law or agreed to in writing, software
  12. * distributed under the License is distributed on an "AS IS" BASIS,
  13. * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
  14. * See the License for the specific language governing permissions and
  15. * limitations under the License.
  16. *
  17. **************************************************************************/
  18. #ifndef REALM_GROUP_SHARED_HPP
  19. #define REALM_GROUP_SHARED_HPP
  20. #include <realm/db_options.hpp>
  21. #include <realm/group.hpp>
  22. #include <realm/handover_defs.hpp>
  23. #include <realm/impl/transact_log.hpp>
  24. #include <realm/metrics/metrics.hpp>
  25. #include <realm/replication.hpp>
  26. #include <realm/util/features.h>
  27. #include <realm/util/interprocess_condvar.hpp>
  28. #include <realm/util/interprocess_mutex.hpp>
  29. #include <realm/version_id.hpp>
  30. #include <functional>
  31. #include <cstdint>
  32. #include <limits>
  33. namespace realm {
  34. namespace _impl {
  35. class WriteLogCollector;
  36. }
  37. class Transaction;
  38. using TransactionRef = std::shared_ptr<Transaction>;
  39. /// Thrown by DB::create() if the lock file is already open in another
  40. /// process which can't share mutexes with this process
  41. struct IncompatibleLockFile : std::runtime_error {
  42. IncompatibleLockFile(const std::string& msg)
  43. : std::runtime_error("Incompatible lock file. " + msg)
  44. {
  45. }
  46. };
  47. /// Thrown by DB::create() if the type of history
  48. /// (Replication::HistoryType) in the opened Realm file is incompatible with the
  49. /// mode in which the Realm file is opened. For example, if there is a mismatch
  50. /// between the history type in the file, and the history type associated with
  51. /// the replication plugin passed to DB::create().
  52. ///
  53. /// This exception will also be thrown if the history schema version is lower
  54. /// than required, and no migration is possible
  55. /// (Replication::is_upgradable_history_schema()).
  56. struct IncompatibleHistories : util::File::AccessError {
  57. IncompatibleHistories(const std::string& msg, const std::string& path)
  58. : util::File::AccessError("Incompatible histories. " + msg, path)
  59. {
  60. }
  61. };
  62. /// The FileFormatUpgradeRequired exception can be thrown by the DB
  63. /// constructor when opening a database that uses a deprecated file format
  64. /// and/or a deprecated history schema, and the user has indicated he does not
  65. /// want automatic upgrades to be performed. This exception indicates that until
  66. /// an upgrade of the file format is performed, the database will be unavailable
  67. /// for read or write operations.
  68. /// It will also be thrown if a realm which requires upgrade is opened in read-only
  69. /// mode (Group::open).
  70. struct FileFormatUpgradeRequired : util::File::AccessError {
  71. FileFormatUpgradeRequired(const std::string& msg, const std::string& path)
  72. : util::File::AccessError(msg, path)
  73. {
  74. }
  75. };
  76. /// A DB facilitates transactions.
  77. ///
  78. /// Access to a database is done through transactions. Transactions
  79. /// are created by a DB object. No matter how many transactions you
  80. /// use, you only need a single DB object per file. Methods on the DB
  81. /// object are thread-safe.
  82. ///
  83. /// Realm has 3 types of Transactions:
  84. /// * A frozen transaction allows read only access
  85. /// * A read transaction allows read only access but can be promoted
  86. /// to a write transaction.
  87. /// * A write transaction allows write access. A write transaction can
  88. /// be demoted to a read transaction.
  89. ///
  90. /// Frozen transactions are thread safe. Read and write transactions are not.
  91. ///
  92. /// Two processes that want to share a database file must reside on
  93. /// the same host.
  94. ///
  95. class DB;
  96. using DBRef = std::shared_ptr<DB>;
  97. class DB : public std::enable_shared_from_this<DB> {
  98. public:
  99. // Create a DB and associate it with a file. DB Objects can only be associated with one file,
  100. // the association determined on creation of the DB Object. The association can be broken by
  101. // calling DB::close(), but after that no new association can be established. To reopen the
  102. // file (or another file), a new DB object is needed.
  103. static DBRef create(const std::string& file, bool no_create = false, const DBOptions options = DBOptions());
  104. static DBRef create(Replication& repl, const DBOptions options = DBOptions());
  105. static DBRef create(std::unique_ptr<Replication> repl, const DBOptions options = DBOptions());
  106. static DBRef create(BinaryData, bool take_ownership = true);
  107. ~DB() noexcept;
  108. // Disable copying to prevent accessor errors. If you really want another
  109. // instance, open another DB object on the same file. But you don't.
  110. DB(const DB&) = delete;
  111. DB& operator=(const DB&) = delete;
  112. /// Close an open database. Calling close() is thread-safe with respect to
  113. /// other calls to close and with respect to deleting transactions.
  114. /// Calling close() while a write transaction is open is an error and close()
  115. /// will throw a LogicError::wrong_transact_state.
  116. /// Calling close() while a read transaction is open is by default treated
  117. /// in the same way, but close(true) will allow the error to be ignored and
  118. /// release resources despite open read transactions.
  119. /// As successfull call to close() leaves transactions (and any associated
  120. /// accessors) in a defunct state and the actual close() operation is not
  121. /// interlocked with access through those accessors, so any access through accessors
  122. /// may constitute a race with a call to close().
  123. /// Instead of using DB::close() to release resources, we recommend using transactions
  124. /// to control release as follows:
  125. /// * explicitly nullify TransactionRefs at earliest time possible and
  126. /// * for read or write transactions - but not frozen transactions, explicitly call
  127. /// close() at earliest time possible
  128. /// * explicitly nullify any DBRefs you may have.
  129. void close(bool allow_open_read_transactions = false);
  130. bool is_attached() const noexcept;
  131. Allocator& get_alloc()
  132. {
  133. return m_alloc;
  134. }
  135. Replication* get_replication() const
  136. {
  137. return m_replication;
  138. }
  139. void set_replication(Replication* repl) noexcept
  140. {
  141. m_replication = repl;
  142. }
  143. const std::string& get_path() const
  144. {
  145. return m_db_path;
  146. }
  147. #ifdef REALM_DEBUG
  148. /// Deprecated method, only called from a unit test
  149. ///
  150. /// Reserve disk space now to avoid allocation errors at a later
  151. /// point in time, and to minimize on-disk fragmentation. In some
  152. /// cases, less fragmentation translates into improved
  153. /// performance.
  154. ///
  155. /// When supported by the system, a call to this function will
  156. /// make the database file at least as big as the specified size,
  157. /// and cause space on the target device to be allocated (note
  158. /// that on many systems on-disk allocation is done lazily by
  159. /// default). If the file is already bigger than the specified
  160. /// size, the size will be unchanged, and on-disk allocation will
  161. /// occur only for the initial section that corresponds to the
  162. /// specified size.
  163. ///
  164. /// It is an error to call this function on an unattached shared
  165. /// group. Doing so will result in undefined behavior.
  166. void reserve(size_t size_in_bytes);
  167. #endif
  168. /// Querying for changes:
  169. ///
  170. /// NOTE:
  171. /// "changed" means that one or more commits has been made to the database
  172. /// since the presented transaction was made.
  173. ///
  174. /// No distinction is made between changes done by another process
  175. /// and changes done by another thread in the same process as the caller.
  176. ///
  177. /// Has db been changed ?
  178. bool has_changed(TransactionRef);
  179. /// The calling thread goes to sleep until the database is changed, or
  180. /// until wait_for_change_release() is called. After a call to
  181. /// wait_for_change_release() further calls to wait_for_change() will return
  182. /// immediately. To restore the ability to wait for a change, a call to
  183. /// enable_wait_for_change() is required. Return true if the database has
  184. /// changed, false if it might have.
  185. bool wait_for_change(TransactionRef);
  186. /// release any thread waiting in wait_for_change().
  187. void wait_for_change_release();
  188. /// re-enable waiting for change
  189. void enable_wait_for_change();
  190. // Transactions:
  191. using version_type = _impl::History::version_type;
  192. using VersionID = realm::VersionID;
  193. /// Returns the version of the latest snapshot.
  194. version_type get_version_of_latest_snapshot();
  195. VersionID get_version_id_of_latest_snapshot();
  196. /// Thrown by start_read() if the specified version does not correspond to a
  197. /// bound (AKA tethered) snapshot.
  198. struct BadVersion;
  199. /// Transactions are obtained from one of the following 3 methods:
  200. TransactionRef start_read(VersionID = VersionID());
  201. TransactionRef start_frozen(VersionID = VersionID());
  202. // If nonblocking is true and a write transaction is already active,
  203. // an invalid TransactionRef is returned.
  204. TransactionRef start_write(bool nonblocking = false);
  205. // report statistics of last commit done on THIS DB.
  206. // The free space reported is what can be expected to be freed
  207. // by compact(). This may not correspond to the space which is free
  208. // at the point where get_stats() is called, since that will include
  209. // memory required to hold older versions of data, which still
  210. // needs to be available. The locked space is the amount of memory
  211. // that is free in current version, but being used in still live versions.
  212. // Notice that we will always have two live versions - the current and the
  213. // previous.
  214. void get_stats(size_t& free_space, size_t& used_space, util::Optional<size_t&> locked_space = util::none) const;
  215. //@}
  216. enum TransactStage {
  217. transact_Ready,
  218. transact_Reading,
  219. transact_Writing,
  220. transact_Frozen,
  221. };
  222. /// Report the number of distinct versions currently stored in the database.
  223. /// Note: the database only cleans up versions as part of commit, so ending
  224. /// a read transaction will not immediately release any versions.
  225. uint_fast64_t get_number_of_versions();
  226. /// Get the size of the currently allocated slab area
  227. size_t get_allocated_size() const;
  228. /// Compact the database file.
  229. /// - The method will throw if called inside a transaction.
  230. /// - The method will throw if called in unattached state.
  231. /// - The method will return false if other DBs are accessing the
  232. /// database in which case compaction is not done. This is not
  233. /// necessarily an error.
  234. /// It will return true following successful compaction.
  235. /// While compaction is in progress, attempts by other
  236. /// threads or processes to open the database will wait.
  237. /// Likewise, attempts to create new transactions will wait.
  238. /// Be warned that resource requirements for compaction is proportional to
  239. /// the amount of live data in the database.
  240. /// Compaction works by writing the database contents to a temporary
  241. /// database file and then replacing the database with the temporary one.
  242. /// The name of the temporary file is formed by appending
  243. /// ".tmp_compaction_space" to the name of the database
  244. ///
  245. /// If the output_encryption_key is `none` then the file's existing key will
  246. /// be used (if any). If the output_encryption_key is nullptr, the resulting
  247. /// file will be unencrypted. Any other value will change the encryption of
  248. /// the file to the new 64 byte key.
  249. ///
  250. /// WARNING: Compact() is not thread-safe with respect to a concurrent close()
  251. bool compact(bool bump_version_number = false, util::Optional<const char*> output_encryption_key = util::none);
  252. void write_copy(StringData path, util::Optional<const char*> output_encryption_key = util::none,
  253. bool allow_overwrite = false);
  254. #ifdef REALM_DEBUG
  255. void test_ringbuf();
  256. #endif
  257. /// The relation between accessors, threads and the Transaction object.
  258. ///
  259. /// Once created, accessors belong to a transaction and can only be used for
  260. /// access as long as that transaction is still active. Copies of accessors
  261. /// can be created in association with another transaction, the importing transaction,
  262. /// using said transactions import_copy_of() method. This process is called
  263. /// accessor import. Prior to Core 6, the corresponding mechanism was known
  264. /// as "handover".
  265. ///
  266. /// For TableViews, there are 3 forms of import determined by the PayloadPolicy.
  267. ///
  268. /// - with payload move: the payload imported ends up as a payload
  269. /// held by the accessor at the importing side. The accessor on the
  270. /// exporting side will rerun its query and generate a new payload, if
  271. /// TableView::sync_if_needed() is called. If the original payload was in
  272. /// sync at the exporting side, it will also be in sync at the importing
  273. /// side. This policy is selected by PayloadPolicy::Move
  274. ///
  275. /// - with payload copy: a copy of the payload is imported, so both the
  276. /// accessors on the exporting side *and* the accessors created at the
  277. /// importing side has their own payload. This is policy is selected
  278. /// by PayloadPolicy::Copy
  279. ///
  280. /// - without payload: the payload stays with the accessor on the exporting
  281. /// side. On the importing side, the new accessor is created without
  282. /// payload. A call to TableView::sync_if_needed() will trigger generation
  283. /// of a new payload. This policy is selected by PayloadPolicy::Stay.
  284. ///
  285. /// For all other (non-TableView) accessors, importing is done with payload
  286. /// copy, since the payload is trivial.
  287. ///
  288. /// Importing *without* payload is useful when you want to ship a tableview
  289. /// with its query for execution in a background thread. Handover with
  290. /// *payload move* is useful when you want to transfer the result back.
  291. ///
  292. /// Importing *without* payload or with payload copy is guaranteed *not* to
  293. /// change the accessors on the exporting side.
  294. ///
  295. /// Importing is generally *not* thread safe and should be carried out
  296. /// by the thread that "owns" the involved accessors. However, importing
  297. /// *is* thread-safe when it occurs from a *frozen* accessor.
  298. ///
  299. /// Importing is transitive:
  300. /// If the object being imported depends on other views
  301. /// (table- or link- ), those objects will be imported as well. The mode
  302. /// (payload copy, payload move, without payload) is applied
  303. /// recursively. Note: If you are importing a tableview dependent upon
  304. /// another tableview and using MutableSourcePayload::Move,
  305. /// you are on thin ice!
  306. ///
  307. /// On the importing side, the top-level accessor being created during
  308. /// import takes ownership of all other accessors (if any) being created as
  309. /// part of the import.
  310. std::shared_ptr<metrics::Metrics> get_metrics()
  311. {
  312. return m_metrics;
  313. }
  314. // Try to grab an exclusive lock of the given realm path's lock file. If the lock
  315. // can be acquired, the callback will be executed with the lock and then return true.
  316. // Otherwise false will be returned directly.
  317. // The lock taken precludes races with other threads or processes accessing the
  318. // files through a DB.
  319. // It is safe to delete/replace realm files inside the callback.
  320. // WARNING: It is not safe to delete the lock file in the callback.
  321. using CallbackWithLock = std::function<void(const std::string& realm_path)>;
  322. static bool call_with_lock(const std::string& realm_path, CallbackWithLock callback);
  323. enum CoreFileType : uint8_t {
  324. Lock,
  325. Storage,
  326. Management,
  327. Note,
  328. Log,
  329. LogA, // This is a legacy version of `Log`.
  330. LogB, // This is a legacy version of `Log`.
  331. };
  332. /// Get the path for the given type of file for a base Realm file path.
  333. /// \param realm_path The path for the main Realm file.
  334. /// \param type The type of associated file to get the path for.
  335. /// \return The base path with the appropriate type-specific suffix appended to it.
  336. static std::string get_core_file(const std::string& realm_path, CoreFileType type);
  337. /// Delete a Realm file and all associated control files.
  338. ///
  339. /// This function does not perform any locking and requires external
  340. /// synchronization to ensure that it is safe to call. If called within
  341. /// call_with_lock(), \p delete_lockfile must be false as the lockfile is not
  342. /// safe to delete while it is in use.
  343. ///
  344. /// \param base_path The Realm file to delete, which auxiliary file paths will be derived from.
  345. /// \param[out] did_delete_realm If non-null, will be set to true if the Realm file was deleted (even if a
  346. /// subsequent deletion failed)
  347. /// \param delete_lockfile By default the lock file is not deleted as it is unsafe to
  348. /// do so. If this is true, the lock file is deleted along with the other files.
  349. static void delete_files(const std::string& base_path, bool* did_delete_realm = nullptr,
  350. bool delete_lockfile = false);
  351. /// Mark this DB as the sync agent for the file.
  352. /// \throw MultipleSyncAgents if another DB is already the sync agent.
  353. void claim_sync_agent();
  354. void release_sync_agent();
  355. protected:
  356. explicit DB(const DBOptions& options); // Is this ever used?
  357. private:
  358. std::recursive_mutex m_mutex;
  359. int m_transaction_count = 0;
  360. SlabAlloc m_alloc;
  361. std::unique_ptr<Replication> m_history;
  362. Replication* m_replication = nullptr;
  363. struct SharedInfo;
  364. struct ReadCount;
  365. struct ReadLockInfo {
  366. uint_fast64_t m_version = std::numeric_limits<version_type>::max();
  367. uint_fast32_t m_reader_idx = 0;
  368. ref_type m_top_ref = 0;
  369. size_t m_file_size = 0;
  370. // a little helper
  371. static std::unique_ptr<ReadLockInfo> make_fake(ref_type top_ref, size_t file_size)
  372. {
  373. auto res = std::make_unique<ReadLockInfo>();
  374. res->m_top_ref = top_ref;
  375. res->m_file_size = file_size;
  376. return res;
  377. }
  378. };
  379. class ReadLockGuard;
  380. // Member variables
  381. size_t m_free_space = 0;
  382. size_t m_locked_space = 0;
  383. size_t m_used_space = 0;
  384. uint_fast32_t m_local_max_entry = 0; // highest version observed by this DB
  385. std::vector<ReadLockInfo> m_local_locks_held; // tracks all read locks held by this DB
  386. util::File m_file;
  387. util::File::Map<SharedInfo> m_file_map; // Never remapped, provides access to everything but the ringbuffer
  388. util::File::Map<SharedInfo> m_reader_map; // provides access to ringbuffer, remapped as needed when it grows
  389. bool m_wait_for_change_enabled = true; // Initially wait_for_change is enabled
  390. bool m_write_transaction_open = false;
  391. std::string m_lockfile_path;
  392. std::string m_lockfile_prefix;
  393. std::string m_db_path;
  394. std::string m_coordination_dir;
  395. const char* m_key;
  396. int m_file_format_version = 0;
  397. util::InterprocessMutex m_writemutex;
  398. std::unique_ptr<ReadLockInfo> m_fake_read_lock_if_immutable;
  399. #ifdef REALM_ASYNC_DAEMON
  400. util::InterprocessMutex m_balancemutex;
  401. #endif
  402. util::InterprocessMutex m_controlmutex;
  403. #ifdef REALM_ASYNC_DAEMON
  404. util::InterprocessCondVar m_room_to_write;
  405. util::InterprocessCondVar m_work_to_do;
  406. util::InterprocessCondVar m_daemon_becomes_ready;
  407. #endif
  408. util::InterprocessCondVar m_new_commit_available;
  409. util::InterprocessCondVar m_pick_next_writer;
  410. std::function<void(int, int)> m_upgrade_callback;
  411. std::shared_ptr<metrics::Metrics> m_metrics;
  412. bool m_is_sync_agent = false;
  413. /// Attach this DB instance to the specified database file.
  414. ///
  415. /// While at least one instance of DB exists for a specific
  416. /// database file, a "lock" file will be present too. The lock file will be
  417. /// placed in the same directory as the database file, and its name will be
  418. /// derived by appending ".lock" to the name of the database file.
  419. ///
  420. /// When multiple DB instances refer to the same file, they must
  421. /// specify the same durability level, otherwise an exception will be
  422. /// thrown.
  423. ///
  424. /// \param file Filesystem path to a Realm database file.
  425. ///
  426. /// \param no_create If the database file does not already exist, it will be
  427. /// created (unless this is set to true.) When multiple threads are involved,
  428. /// it is safe to let the first thread, that gets to it, create the file.
  429. ///
  430. /// \param options See DBOptions for details of each option.
  431. /// Sensible defaults are provided if this parameter is left out.
  432. ///
  433. /// \throw util::File::AccessError If the file could not be opened. If the
  434. /// reason corresponds to one of the exception types that are derived from
  435. /// util::File::AccessError, the derived exception type is thrown. Note that
  436. /// InvalidDatabase is among these derived exception types.
  437. ///
  438. /// \throw FileFormatUpgradeRequired if \a DBOptions::allow_upgrade
  439. /// is `false` and an upgrade is required.
  440. ///
  441. /// \throw LogicError if both DBOptions::allow_upgrade and is_immutable is true.
  442. /// \throw UnsupportedFileFormatVersion if the file format version or
  443. /// history schema version is one which this version of Realm does not know
  444. /// how to migrate from.
  445. void open(const std::string& file, bool no_create = false, const DBOptions options = DBOptions());
  446. void open(BinaryData, bool take_ownership = true);
  447. /// Open this group in replication mode. The specified Replication instance
  448. /// must remain in existence for as long as the DB.
  449. void open(Replication&, const DBOptions options = DBOptions());
  450. void do_open(const std::string& file, bool no_create, bool is_backend, const DBOptions options);
  451. Replication* const* get_repl() const noexcept
  452. {
  453. return &m_replication;
  454. }
  455. // Ring buffer management
  456. bool ringbuf_is_empty() const noexcept;
  457. size_t ringbuf_size() const noexcept;
  458. size_t ringbuf_capacity() const noexcept;
  459. bool ringbuf_is_first(size_t ndx) const noexcept;
  460. void ringbuf_remove_first() noexcept;
  461. size_t ringbuf_find(uint64_t version) const noexcept;
  462. ReadCount& ringbuf_get(size_t ndx) noexcept;
  463. ReadCount& ringbuf_get_first() noexcept;
  464. ReadCount& ringbuf_get_last() noexcept;
  465. void ringbuf_put(const ReadCount& v);
  466. void ringbuf_expand();
  467. /// Grab a read lock on the snapshot associated with the specified
  468. /// version. If `version_id == VersionID()`, a read lock will be grabbed on
  469. /// the latest available snapshot. Fails if the snapshot is no longer
  470. /// available.
  471. ///
  472. /// As a side effect update memory mapping to ensure that the ringbuffer
  473. /// entries referenced in the readlock info is accessible.
  474. void grab_read_lock(ReadLockInfo&, VersionID);
  475. // Release a specific read lock. The read lock MUST have been obtained by a
  476. // call to grab_read_lock().
  477. void release_read_lock(ReadLockInfo&) noexcept;
  478. // Release all read locks held by this DB object. After release, further calls to
  479. // release_read_lock for locks already released must be avoided.
  480. void release_all_read_locks() noexcept;
  481. /// return true if write transaction can commence, false otherwise.
  482. bool do_try_begin_write();
  483. void do_begin_write();
  484. version_type do_commit(Transaction&);
  485. void do_end_write() noexcept;
  486. // make sure the given index is within the currently mapped area.
  487. // if not, expand the mapped area. Returns true if the area is expanded.
  488. bool grow_reader_mapping(uint_fast32_t index);
  489. // Must be called only by someone that has a lock on the write mutex.
  490. void low_level_commit(uint_fast64_t new_version, Transaction& transaction);
  491. void do_async_commits();
  492. /// Upgrade file format and/or history schema
  493. void upgrade_file_format(bool allow_file_format_upgrade, int target_file_format_version,
  494. int current_hist_schema_version, int target_hist_schema_version);
  495. int get_file_format_version() const noexcept;
  496. /// finish up the process of starting a write transaction. Internal use only.
  497. void finish_begin_write();
  498. void reset_free_space_tracking()
  499. {
  500. m_alloc.reset_free_space_tracking();
  501. }
  502. void close_internal(std::unique_lock<util::InterprocessMutex>, bool allow_open_read_transactions);
  503. friend class Transaction;
  504. };
  505. inline void DB::get_stats(size_t& free_space, size_t& used_space, util::Optional<size_t&> locked_space) const
  506. {
  507. free_space = m_free_space;
  508. used_space = m_used_space;
  509. if (locked_space) {
  510. *locked_space = m_locked_space;
  511. }
  512. }
  513. class Transaction : public Group {
  514. public:
  515. Transaction(DBRef _db, SlabAlloc* alloc, DB::ReadLockInfo& rli, DB::TransactStage stage);
  516. // convenience, so you don't need to carry a reference to the DB around
  517. ~Transaction();
  518. DB::version_type get_version() const noexcept
  519. {
  520. return m_read_lock.m_version;
  521. }
  522. DB::version_type get_version_of_latest_snapshot()
  523. {
  524. return db->get_version_of_latest_snapshot();
  525. }
  526. void close();
  527. bool is_attached()
  528. {
  529. return m_transact_stage != DB::transact_Ready && db->is_attached();
  530. }
  531. /// Get the approximate size of the data that would be written to the file if
  532. /// a commit were done at this point. The reported size will always be bigger
  533. /// than what will eventually be needed as we reserve a bit more memory than
  534. /// what will be needed.
  535. size_t get_commit_size() const;
  536. DB::version_type commit();
  537. void rollback();
  538. void end_read();
  539. // Live transactions state changes, often taking an observer functor:
  540. VersionID commit_and_continue_as_read();
  541. template <class O>
  542. void rollback_and_continue_as_read(O* observer);
  543. void rollback_and_continue_as_read()
  544. {
  545. _impl::NullInstructionObserver* o = nullptr;
  546. rollback_and_continue_as_read(o);
  547. }
  548. template <class O>
  549. void advance_read(O* observer, VersionID target_version = VersionID());
  550. void advance_read(VersionID target_version = VersionID())
  551. {
  552. _impl::NullInstructionObserver* o = nullptr;
  553. advance_read(o, target_version);
  554. }
  555. template <class O>
  556. bool promote_to_write(O* observer, bool nonblocking = false);
  557. bool promote_to_write(bool nonblocking = false)
  558. {
  559. _impl::NullInstructionObserver* o = nullptr;
  560. return promote_to_write(o, nonblocking);
  561. }
  562. TransactionRef freeze();
  563. // Frozen transactions are created by freeze() or DB::start_frozen()
  564. bool is_frozen() const noexcept override
  565. {
  566. return m_transact_stage == DB::transact_Frozen;
  567. }
  568. TransactionRef duplicate();
  569. _impl::History* get_history() const;
  570. // direct handover of accessor instances
  571. Obj import_copy_of(const Obj& original);
  572. TableRef import_copy_of(const ConstTableRef original);
  573. LnkLst import_copy_of(const LnkLst& original);
  574. LnkSet import_copy_of(const LnkSet& original);
  575. LstBasePtr import_copy_of(const LstBase& original);
  576. SetBasePtr import_copy_of(const SetBase& original);
  577. CollectionBasePtr import_copy_of(const CollectionBase& original);
  578. LnkLstPtr import_copy_of(const LnkLstPtr& original);
  579. LnkSetPtr import_copy_of(const LnkSetPtr& original);
  580. LinkCollectionPtr import_copy_of(const LinkCollectionPtr& original);
  581. // handover of the heavier Query and TableView
  582. std::unique_ptr<Query> import_copy_of(Query&, PayloadPolicy);
  583. std::unique_ptr<TableView> import_copy_of(TableView&, PayloadPolicy);
  584. std::unique_ptr<ConstTableView> import_copy_of(ConstTableView&, PayloadPolicy);
  585. /// Get the current transaction type
  586. DB::TransactStage get_transact_stage() const noexcept;
  587. /// Get a version id which may be used to request a different transaction locked to specific version.
  588. VersionID get_version_of_current_transaction();
  589. void upgrade_file_format(int target_file_format_version);
  590. private:
  591. DBRef get_db() const
  592. {
  593. return db;
  594. }
  595. Replication* const* get_repl() const final
  596. {
  597. return db->get_repl();
  598. }
  599. template <class O>
  600. bool internal_advance_read(O* observer, VersionID target_version, _impl::History&, bool);
  601. void set_transact_stage(DB::TransactStage stage) noexcept;
  602. void do_end_read() noexcept;
  603. void commit_and_continue_writing();
  604. void initialize_replication();
  605. DBRef db;
  606. mutable std::unique_ptr<_impl::History> m_history_read;
  607. mutable _impl::History* m_history = nullptr;
  608. DB::ReadLockInfo m_read_lock;
  609. DB::TransactStage m_transact_stage = DB::transact_Ready;
  610. friend class DB;
  611. friend class DisableReplication;
  612. };
  613. class DisableReplication {
  614. public:
  615. DisableReplication(Transaction& t)
  616. : m_tr(t)
  617. , m_owner(t.get_db())
  618. , m_repl(m_owner->get_replication())
  619. , m_version(t.get_version())
  620. {
  621. m_owner->set_replication(nullptr);
  622. t.get_version();
  623. t.m_history = nullptr;
  624. }
  625. ~DisableReplication()
  626. {
  627. m_owner->set_replication(m_repl);
  628. if (m_version != m_tr.get_version())
  629. m_tr.initialize_replication();
  630. }
  631. private:
  632. Transaction& m_tr;
  633. DBRef m_owner;
  634. Replication* m_repl;
  635. DB::version_type m_version;
  636. };
  637. /*
  638. * classes providing backward Compatibility with the older
  639. * ReadTransaction and WriteTransaction types.
  640. */
  641. class ReadTransaction {
  642. public:
  643. ReadTransaction(DBRef sg)
  644. : trans(sg->start_read())
  645. {
  646. }
  647. ~ReadTransaction() noexcept {}
  648. operator Transaction&()
  649. {
  650. return *trans;
  651. }
  652. bool has_table(StringData name) const noexcept
  653. {
  654. return trans->has_table(name);
  655. }
  656. ConstTableRef get_table(TableKey key) const
  657. {
  658. return trans->get_table(key); // Throws
  659. }
  660. ConstTableRef get_table(StringData name) const
  661. {
  662. return trans->get_table(name); // Throws
  663. }
  664. const Group& get_group() const noexcept
  665. {
  666. return *trans.get();
  667. }
  668. /// Get the version of the snapshot to which this read transaction is bound.
  669. DB::version_type get_version() const noexcept
  670. {
  671. return trans->get_version();
  672. }
  673. private:
  674. TransactionRef trans;
  675. };
  676. class WriteTransaction {
  677. public:
  678. WriteTransaction(DBRef sg)
  679. : trans(sg->start_write())
  680. {
  681. }
  682. ~WriteTransaction() noexcept {}
  683. operator Transaction&()
  684. {
  685. return *trans;
  686. }
  687. bool has_table(StringData name) const noexcept
  688. {
  689. return trans->has_table(name);
  690. }
  691. TableRef get_table(TableKey key) const
  692. {
  693. return trans->get_table(key); // Throws
  694. }
  695. TableRef get_table(StringData name) const
  696. {
  697. return trans->get_table(name); // Throws
  698. }
  699. TableRef add_table(StringData name) const
  700. {
  701. return trans->add_table(name); // Throws
  702. }
  703. TableRef add_embedded_table(StringData name) const
  704. {
  705. return trans->add_embedded_table(name); // Throws
  706. }
  707. TableRef get_or_add_table(StringData name, bool* was_added = nullptr) const
  708. {
  709. return trans->get_or_add_table(name, was_added); // Throws
  710. }
  711. Group& get_group() const noexcept
  712. {
  713. return *trans.get();
  714. }
  715. /// Get the version of the snapshot on which this write transaction is
  716. /// based.
  717. DB::version_type get_version() const noexcept
  718. {
  719. return trans->get_version();
  720. }
  721. DB::version_type commit()
  722. {
  723. return trans->commit();
  724. }
  725. void rollback() noexcept
  726. {
  727. trans->rollback();
  728. }
  729. private:
  730. TransactionRef trans;
  731. };
  732. // Implementation:
  733. struct DB::BadVersion : std::exception {
  734. };
  735. inline bool DB::is_attached() const noexcept
  736. {
  737. return bool(m_fake_read_lock_if_immutable) || m_file_map.is_attached();
  738. }
  739. inline DB::TransactStage Transaction::get_transact_stage() const noexcept
  740. {
  741. return m_transact_stage;
  742. }
  743. class DB::ReadLockGuard {
  744. public:
  745. ReadLockGuard(DB& shared_group, ReadLockInfo& read_lock) noexcept
  746. : m_db(shared_group)
  747. , m_read_lock(&read_lock)
  748. {
  749. }
  750. ~ReadLockGuard() noexcept
  751. {
  752. if (m_read_lock)
  753. m_db.release_read_lock(*m_read_lock);
  754. }
  755. void release() noexcept
  756. {
  757. m_read_lock = 0;
  758. }
  759. private:
  760. DB& m_db;
  761. ReadLockInfo* m_read_lock;
  762. };
  763. template <class O>
  764. inline void Transaction::advance_read(O* observer, VersionID version_id)
  765. {
  766. if (m_transact_stage != DB::transact_Reading)
  767. throw LogicError(LogicError::wrong_transact_state);
  768. // It is an error if the new version precedes the currently bound one.
  769. if (version_id.version < m_read_lock.m_version)
  770. throw LogicError(LogicError::bad_version);
  771. auto hist = get_history(); // Throws
  772. if (!hist)
  773. throw LogicError(LogicError::no_history);
  774. internal_advance_read(observer, version_id, *hist, false); // Throws
  775. }
  776. template <class O>
  777. inline bool Transaction::promote_to_write(O* observer, bool nonblocking)
  778. {
  779. if (m_transact_stage != DB::transact_Reading)
  780. throw LogicError(LogicError::wrong_transact_state);
  781. if (nonblocking) {
  782. bool succes = db->do_try_begin_write();
  783. if (!succes) {
  784. return false;
  785. }
  786. }
  787. else {
  788. db->do_begin_write(); // Throws
  789. }
  790. try {
  791. Replication* repl = db->get_replication();
  792. if (!repl)
  793. throw LogicError(LogicError::no_history);
  794. VersionID version = VersionID(); // Latest
  795. m_history = repl->_get_history_write();
  796. bool history_updated = internal_advance_read(observer, version, *m_history, true); // Throws
  797. REALM_ASSERT(repl); // Presence of `repl` follows from the presence of `hist`
  798. DB::version_type current_version = m_read_lock.m_version;
  799. m_alloc.init_mapping_management(current_version);
  800. repl->initiate_transact(*this, current_version, history_updated); // Throws
  801. // If the group has no top array (top_ref == 0), create a new node
  802. // structure for an empty group now, to be ready for modifications. See
  803. // also Group::attach_shared().
  804. if (!m_top.is_attached())
  805. create_empty_group(); // Throws
  806. }
  807. catch (...) {
  808. db->do_end_write();
  809. m_history = nullptr;
  810. throw;
  811. }
  812. set_transact_stage(DB::transact_Writing);
  813. return true;
  814. }
  815. template <class O>
  816. inline void Transaction::rollback_and_continue_as_read(O* observer)
  817. {
  818. if (m_transact_stage != DB::transact_Writing)
  819. throw LogicError(LogicError::wrong_transact_state);
  820. Replication* repl = db->get_replication();
  821. if (!repl)
  822. throw LogicError(LogicError::no_history);
  823. BinaryData uncommitted_changes = repl->get_uncommitted_changes();
  824. // Possible optimization: We are currently creating two transaction log parsers, one here,
  825. // and one in advance_transact(). That is wasteful as the parser creation is
  826. // expensive.
  827. _impl::SimpleInputStream in(uncommitted_changes.data(), uncommitted_changes.size());
  828. _impl::TransactLogParser parser; // Throws
  829. _impl::TransactReverser reverser;
  830. parser.parse(in, reverser); // Throws
  831. if (observer && uncommitted_changes.size()) {
  832. _impl::ReversedNoCopyInputStream reversed_in(reverser);
  833. parser.parse(reversed_in, *observer); // Throws
  834. observer->parse_complete(); // Throws
  835. }
  836. // Mark all managed space (beyond the attached file) as free.
  837. db->reset_free_space_tracking(); // Throws
  838. ref_type top_ref = m_read_lock.m_top_ref;
  839. size_t file_size = m_read_lock.m_file_size;
  840. _impl::ReversedNoCopyInputStream reversed_in(reverser);
  841. m_alloc.update_reader_view(file_size); // Throws
  842. update_allocator_wrappers(false);
  843. advance_transact(top_ref, reversed_in, false); // Throws
  844. db->do_end_write();
  845. repl->abort_transact();
  846. m_history = nullptr;
  847. set_transact_stage(DB::transact_Reading);
  848. }
  849. template <class O>
  850. inline bool Transaction::internal_advance_read(O* observer, VersionID version_id, _impl::History& hist, bool writable)
  851. {
  852. DB::ReadLockInfo new_read_lock;
  853. db->grab_read_lock(new_read_lock, version_id); // Throws
  854. REALM_ASSERT(new_read_lock.m_version >= m_read_lock.m_version);
  855. if (new_read_lock.m_version == m_read_lock.m_version) {
  856. db->release_read_lock(new_read_lock);
  857. // _impl::History::update_early_from_top_ref() was not called
  858. // update allocator wrappers merely to update write protection
  859. update_allocator_wrappers(writable);
  860. return false;
  861. }
  862. DB::version_type old_version = m_read_lock.m_version;
  863. DB::ReadLockGuard g(*db, new_read_lock);
  864. DB::version_type new_version = new_read_lock.m_version;
  865. size_t new_file_size = new_read_lock.m_file_size;
  866. ref_type new_top_ref = new_read_lock.m_top_ref;
  867. // Synchronize readers view of the file
  868. SlabAlloc& alloc = m_alloc;
  869. alloc.update_reader_view(new_file_size);
  870. update_allocator_wrappers(writable);
  871. using gf = _impl::GroupFriend;
  872. ref_type hist_ref = gf::get_history_ref(alloc, new_top_ref);
  873. hist.update_from_ref_and_version(hist_ref, new_version);
  874. if (observer) {
  875. // This has to happen in the context of the originally bound snapshot
  876. // and while the read transaction is still in a fully functional state.
  877. _impl::TransactLogParser parser;
  878. _impl::ChangesetInputStream in(hist, old_version, new_version);
  879. parser.parse(in, *observer); // Throws
  880. observer->parse_complete(); // Throws
  881. }
  882. // The old read lock must be retained for as long as the change history is
  883. // accessed (until Group::advance_transact() returns). This ensures that the
  884. // oldest needed changeset remains in the history, even when the history is
  885. // implemented as a separate unversioned entity outside the Realm (i.e., the
  886. // old implementation and ShortCircuitHistory in
  887. // test_lang_Bind_helper.cpp). On the other hand, if it had been the case,
  888. // that the history was always implemented as a versioned entity, that was
  889. // part of the Realm state, then it would not have been necessary to retain
  890. // the old read lock beyond this point.
  891. _impl::ChangesetInputStream in(hist, old_version, new_version);
  892. advance_transact(new_top_ref, in, writable); // Throws
  893. g.release();
  894. db->release_read_lock(m_read_lock);
  895. m_read_lock = new_read_lock;
  896. return true; // _impl::History::update_early_from_top_ref() was called
  897. }
  898. inline int DB::get_file_format_version() const noexcept
  899. {
  900. return m_file_format_version;
  901. }
  902. } // namespace realm
  903. #endif // REALM_GROUP_SHARED_HPP