db.hpp 29 KB

123456789101112131415161718192021222324252627282930313233343536373839404142434445464748495051525354555657585960616263646566676869707172737475767778798081828384858687888990919293949596979899100101102103104105106107108109110111112113114115116117118119120121122123124125126127128129130131132133134135136137138139140141142143144145146147148149150151152153154155156157158159160161162163164165166167168169170171172173174175176177178179180181182183184185186187188189190191192193194195196197198199200201202203204205206207208209210211212213214215216217218219220221222223224225226227228229230231232233234235236237238239240241242243244245246247248249250251252253254255256257258259260261262263264265266267268269270271272273274275276277278279280281282283284285286287288289290291292293294295296297298299300301302303304305306307308309310311312313314315316317318319320321322323324325326327328329330331332333334335336337338339340341342343344345346347348349350351352353354355356357358359360361362363364365366367368369370371372373374375376377378379380381382383384385386387388389390391392393394395396397398399400401402403404405406407408409410411412413414415416417418419420421422423424425426427428429430431432433434435436437438439440441442443444445446447448449450451452453454455456457458459460461462463464465466467468469470471472473474475476477478479480481482483484485486487488489490491492493494495496497498499500501502503504505506507508509510511512513514515516517518519520521522523524525526527528529530531532533534535536537538539540541542543544545546547548549550551552553554555556557558559560561562563564565566567568569570571572573574575576577578579580581582583584585586587588589590591592593594595596597598599600601602603604605606607608609610611612613614615616617618619620621622623624625626627628629630631632633634635636637638639640641642643644645646647648649650651652653654655656657658659660661662663664665666667668669670671672673674675676677678679680681682683684685686687688689690
  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_DB_HPP
  19. #define REALM_DB_HPP
  20. #include <realm/db_options.hpp>
  21. #include <realm/group.hpp>
  22. #include <realm/handover_defs.hpp>
  23. #include <realm/impl/changeset_input_stream.hpp>
  24. #include <realm/impl/transact_log.hpp>
  25. #include <realm/metrics/metrics.hpp>
  26. #include <realm/replication.hpp>
  27. #include <realm/util/checked_mutex.hpp>
  28. #include <realm/util/features.h>
  29. #include <realm/util/functional.hpp>
  30. #include <realm/util/interprocess_condvar.hpp>
  31. #include <realm/util/interprocess_mutex.hpp>
  32. #include <realm/util/encrypted_file_mapping.hpp>
  33. #include <realm/version_id.hpp>
  34. #include <functional>
  35. #include <cstdint>
  36. #include <limits>
  37. #include <condition_variable>
  38. namespace realm {
  39. class Transaction;
  40. using TransactionRef = std::shared_ptr<Transaction>;
  41. /// Thrown by DB::create() if the lock file is already open in another
  42. /// process which can't share mutexes with this process
  43. struct IncompatibleLockFile : FileAccessError {
  44. IncompatibleLockFile(const std::string& path, const std::string& msg)
  45. : FileAccessError(
  46. ErrorCodes::IncompatibleLockFile,
  47. util::format(
  48. "Realm file '%1' is currently open in another process which cannot share access with this process. "
  49. "This could either be due to the existing process being a different architecture or due to the "
  50. "existing process using an incompatible version of Realm. "
  51. "If the other process is Realm Studio, you may need to update it (or update Realm if your Studio "
  52. "version is too new), and if using an iOS simulator, make sure that you are using a 64-bit "
  53. "simulator. Underlying problem: %2",
  54. path, msg),
  55. path)
  56. {
  57. }
  58. };
  59. /// Thrown by DB::create() if the type of history
  60. /// (Replication::HistoryType) in the opened Realm file is incompatible with the
  61. /// mode in which the Realm file is opened. For example, if there is a mismatch
  62. /// between the history type in the file, and the history type associated with
  63. /// the replication plugin passed to DB::create().
  64. ///
  65. /// This exception will also be thrown if the history schema version is lower
  66. /// than required, and no migration is possible
  67. /// (Replication::is_upgradable_history_schema()).
  68. struct IncompatibleHistories : FileAccessError {
  69. IncompatibleHistories(const std::string& msg, const std::string& path)
  70. : FileAccessError(ErrorCodes::IncompatibleHistories,
  71. msg + " Synchronized Realms cannot be opened in non-sync mode, and vice versa.", path)
  72. {
  73. }
  74. };
  75. /// The FileFormatUpgradeRequired exception can be thrown by the DB
  76. /// constructor when opening a database that uses a deprecated file format
  77. /// and/or a deprecated history schema, and the user has indicated he does not
  78. /// want automatic upgrades to be performed. This exception indicates that until
  79. /// an upgrade of the file format is performed, the database will be unavailable
  80. /// for read or write operations.
  81. /// It will also be thrown if a realm which requires upgrade is opened in read-only
  82. /// mode (Group::open).
  83. struct FileFormatUpgradeRequired : FileAccessError {
  84. FileFormatUpgradeRequired(const std::string& path)
  85. : FileAccessError(ErrorCodes::FileFormatUpgradeRequired, "Database upgrade required but prohibited.", path, 0)
  86. {
  87. }
  88. };
  89. /// A DB facilitates transactions.
  90. ///
  91. /// Access to a database is done through transactions. Transactions
  92. /// are created by a DB object. No matter how many transactions you
  93. /// use, you only need a single DB object per file. Methods on the DB
  94. /// object are thread-safe.
  95. ///
  96. /// Realm has 3 types of Transactions:
  97. /// * A frozen transaction allows read only access
  98. /// * A read transaction allows read only access but can be promoted
  99. /// to a write transaction.
  100. /// * A write transaction allows write access. A write transaction can
  101. /// be demoted to a read transaction.
  102. ///
  103. /// Frozen transactions are thread safe. Read and write transactions are not.
  104. ///
  105. /// Two processes that want to share a database file must reside on
  106. /// the same host.
  107. ///
  108. class DB;
  109. using DBRef = std::shared_ptr<DB>;
  110. class DB : public std::enable_shared_from_this<DB> {
  111. struct ReadLockInfo;
  112. public:
  113. // Create a DB and associate it with a file. DB Objects can only be associated with one file,
  114. // the association determined on creation of the DB Object. The association can be broken by
  115. // calling DB::close(), but after that no new association can be established. To reopen the
  116. // file (or another file), a new DB object is needed. The specified Replication instance, if
  117. // any, must remain in existence for as long as the DB.
  118. static DBRef create(const std::string& file, bool no_create = false, const DBOptions& options = DBOptions());
  119. static DBRef create(Replication& repl, const std::string& file, const DBOptions& options = DBOptions());
  120. static DBRef create(std::unique_ptr<Replication> repl, const std::string& file,
  121. const DBOptions& options = DBOptions());
  122. static DBRef create(BinaryData, bool take_ownership = true);
  123. static DBRef create(std::unique_ptr<Replication> repl, const DBOptions& options = DBOptions());
  124. ~DB() noexcept;
  125. // Disable copying to prevent accessor errors. If you really want another
  126. // instance, open another DB object on the same file. But you don't.
  127. DB(const DB&) = delete;
  128. DB& operator=(const DB&) = delete;
  129. /// Close an open database. Calling close() is thread-safe with respect to
  130. /// other calls to close and with respect to deleting transactions.
  131. /// Calling close() while a write transaction is open is an error and close()
  132. /// will throw a LogicError::wrong_transact_state.
  133. /// Calling close() while a read transaction is open is by default treated
  134. /// in the same way, but close(true) will allow the error to be ignored and
  135. /// release resources despite open read transactions.
  136. /// As successfull call to close() leaves transactions (and any associated
  137. /// accessors) in a defunct state and the actual close() operation is not
  138. /// interlocked with access through those accessors, so any access through accessors
  139. /// may constitute a race with a call to close().
  140. /// Instead of using DB::close() to release resources, we recommend using transactions
  141. /// to control release as follows:
  142. /// * explicitly nullify TransactionRefs at earliest time possible and
  143. /// * for read or write transactions - but not frozen transactions, explicitly call
  144. /// close() at earliest time possible
  145. /// * explicitly nullify any DBRefs you may have.
  146. void close(bool allow_open_read_transactions = false) REQUIRES(!m_mutex);
  147. bool is_attached() const noexcept;
  148. Allocator& get_alloc()
  149. {
  150. return m_alloc;
  151. }
  152. Replication* get_replication() const
  153. {
  154. return m_replication;
  155. }
  156. void set_replication(Replication* repl) noexcept
  157. {
  158. m_replication = repl;
  159. }
  160. void set_logger(const std::shared_ptr<util::Logger>& logger) noexcept;
  161. void create_new_history(Replication& repl) REQUIRES(!m_mutex);
  162. void create_new_history(std::unique_ptr<Replication> repl) REQUIRES(!m_mutex);
  163. const std::string& get_path() const noexcept
  164. {
  165. return m_db_path;
  166. }
  167. const char* get_encryption_key() const noexcept
  168. {
  169. return m_alloc.m_file.get_encryption_key();
  170. }
  171. #ifdef REALM_DEBUG
  172. /// Deprecated method, only called from a unit test
  173. ///
  174. /// Reserve disk space now to avoid allocation errors at a later
  175. /// point in time, and to minimize on-disk fragmentation. In some
  176. /// cases, less fragmentation translates into improved
  177. /// performance.
  178. ///
  179. /// When supported by the system, a call to this function will
  180. /// make the database file at least as big as the specified size,
  181. /// and cause space on the target device to be allocated (note
  182. /// that on many systems on-disk allocation is done lazily by
  183. /// default). If the file is already bigger than the specified
  184. /// size, the size will be unchanged, and on-disk allocation will
  185. /// occur only for the initial section that corresponds to the
  186. /// specified size.
  187. ///
  188. /// It is an error to call this function on an unattached shared
  189. /// group. Doing so will result in undefined behavior.
  190. void reserve(size_t size_in_bytes);
  191. #endif
  192. /// Querying for changes:
  193. ///
  194. /// NOTE:
  195. /// "changed" means that one or more commits has been made to the database
  196. /// since the presented transaction was made.
  197. ///
  198. /// No distinction is made between changes done by another process
  199. /// and changes done by another thread in the same process as the caller.
  200. ///
  201. /// Has db been changed ?
  202. bool has_changed(TransactionRef&);
  203. /// The calling thread goes to sleep until the database is changed, or
  204. /// until wait_for_change_release() is called. After a call to
  205. /// wait_for_change_release() further calls to wait_for_change() will return
  206. /// immediately. To restore the ability to wait for a change, a call to
  207. /// enable_wait_for_change() is required. Return true if the database has
  208. /// changed, false if it might have.
  209. bool wait_for_change(TransactionRef&);
  210. /// release any thread waiting in wait_for_change().
  211. void wait_for_change_release();
  212. /// re-enable waiting for change
  213. void enable_wait_for_change();
  214. // Transactions:
  215. using version_type = _impl::History::version_type;
  216. using VersionID = realm::VersionID;
  217. /// Returns the version of the latest snapshot.
  218. version_type get_version_of_latest_snapshot();
  219. VersionID get_version_id_of_latest_snapshot();
  220. /// Thrown by start_read() if the specified version does not correspond to a
  221. /// bound (AKA tethered) snapshot.
  222. struct BadVersion;
  223. /// Transactions are obtained from one of the following 3 methods:
  224. TransactionRef start_read(VersionID = VersionID()) REQUIRES(!m_mutex);
  225. TransactionRef start_frozen(VersionID = VersionID()) REQUIRES(!m_mutex);
  226. // If nonblocking is true and a write transaction is already active,
  227. // an invalid TransactionRef is returned.
  228. TransactionRef start_write(bool nonblocking = false) REQUIRES(!m_mutex);
  229. // ask for write mutex. Callback takes place when mutex has been acquired.
  230. // callback may occur on ANOTHER THREAD. Must not be called if write mutex
  231. // has already been acquired.
  232. void async_request_write_mutex(TransactionRef& tr, util::UniqueFunction<void()>&& when_acquired);
  233. // report statistics of last commit done on THIS DB.
  234. // The free space reported is what can be expected to be freed
  235. // by compact(). This may not correspond to the space which is free
  236. // at the point where get_stats() is called, since that will include
  237. // memory required to hold older versions of data, which still
  238. // needs to be available. The locked space is the amount of memory
  239. // that is free in current version, but being used in still live versions.
  240. // Notice that we will always have two live versions - the current and the
  241. // previous.
  242. void get_stats(size_t& free_space, size_t& used_space, size_t* locked_space = nullptr) const REQUIRES(!m_mutex);
  243. //@}
  244. enum TransactStage {
  245. transact_Ready,
  246. transact_Reading,
  247. transact_Writing,
  248. transact_Frozen,
  249. };
  250. enum class EvacStage { idle, evacuating, waiting, blocked };
  251. EvacStage get_evacuation_stage() const
  252. {
  253. return m_evac_stage;
  254. }
  255. /// Report the number of distinct versions currently stored in the database.
  256. /// Note: the database only cleans up versions as part of commit, so ending
  257. /// a read transaction will not immediately release any versions.
  258. uint_fast64_t get_number_of_versions();
  259. /// Get the size of the currently allocated slab area
  260. size_t get_allocated_size() const;
  261. /// Compact the database file.
  262. /// - The method will throw if called inside a transaction.
  263. /// - The method will throw if called in unattached state.
  264. /// - The method will return false if other DBs are accessing the
  265. /// database in which case compaction is not done. This is not
  266. /// necessarily an error.
  267. /// It will return true following successful compaction.
  268. /// While compaction is in progress, attempts by other
  269. /// threads or processes to open the database will wait.
  270. /// Likewise, attempts to create new transactions will wait.
  271. /// Be warned that resource requirements for compaction is proportional to
  272. /// the amount of live data in the database.
  273. /// Compaction works by writing the database contents to a temporary
  274. /// database file and then replacing the database with the temporary one.
  275. /// The name of the temporary file is formed by appending
  276. /// ".tmp_compaction_space" to the name of the database
  277. ///
  278. /// If the output_encryption_key is `none` then the file's existing key will
  279. /// be used (if any). If the output_encryption_key is nullptr, the resulting
  280. /// file will be unencrypted. Any other value will change the encryption of
  281. /// the file to the new 64 byte key.
  282. ///
  283. /// WARNING: Compact() is not thread-safe with respect to a concurrent close()
  284. bool compact(bool bump_version_number = false, util::Optional<const char*> output_encryption_key = util::none)
  285. REQUIRES(!m_mutex);
  286. void write_copy(StringData path, const char* output_encryption_key) REQUIRES(!m_mutex);
  287. #ifdef REALM_DEBUG
  288. void test_ringbuf();
  289. #endif
  290. /// The relation between accessors, threads and the Transaction object.
  291. ///
  292. /// Once created, accessors belong to a transaction and can only be used for
  293. /// access as long as that transaction is still active. Copies of accessors
  294. /// can be created in association with another transaction, the importing transaction,
  295. /// using said transactions import_copy_of() method. This process is called
  296. /// accessor import. Prior to Core 6, the corresponding mechanism was known
  297. /// as "handover".
  298. ///
  299. /// For TableViews, there are 3 forms of import determined by the PayloadPolicy.
  300. ///
  301. /// - with payload move: the payload imported ends up as a payload
  302. /// held by the accessor at the importing side. The accessor on the
  303. /// exporting side will rerun its query and generate a new payload, if
  304. /// TableView::sync_if_needed() is called. If the original payload was in
  305. /// sync at the exporting side, it will also be in sync at the importing
  306. /// side. This policy is selected by PayloadPolicy::Move
  307. ///
  308. /// - with payload copy: a copy of the payload is imported, so both the
  309. /// accessors on the exporting side *and* the accessors created at the
  310. /// importing side has their own payload. This is policy is selected
  311. /// by PayloadPolicy::Copy
  312. ///
  313. /// - without payload: the payload stays with the accessor on the exporting
  314. /// side. On the importing side, the new accessor is created without
  315. /// payload. A call to TableView::sync_if_needed() will trigger generation
  316. /// of a new payload. This policy is selected by PayloadPolicy::Stay.
  317. ///
  318. /// For all other (non-TableView) accessors, importing is done with payload
  319. /// copy, since the payload is trivial.
  320. ///
  321. /// Importing *without* payload is useful when you want to ship a tableview
  322. /// with its query for execution in a background thread. Handover with
  323. /// *payload move* is useful when you want to transfer the result back.
  324. ///
  325. /// Importing *without* payload or with payload copy is guaranteed *not* to
  326. /// change the accessors on the exporting side.
  327. ///
  328. /// Importing is generally *not* thread safe and should be carried out
  329. /// by the thread that "owns" the involved accessors. However, importing
  330. /// *is* thread-safe when it occurs from a *frozen* accessor.
  331. ///
  332. /// Importing is transitive:
  333. /// If the object being imported depends on other views
  334. /// (table- or link- ), those objects will be imported as well. The mode
  335. /// (payload copy, payload move, without payload) is applied
  336. /// recursively. Note: If you are importing a tableview dependent upon
  337. /// another tableview and using MutableSourcePayload::Move,
  338. /// you are on thin ice!
  339. ///
  340. /// On the importing side, the top-level accessor being created during
  341. /// import takes ownership of all other accessors (if any) being created as
  342. /// part of the import.
  343. std::shared_ptr<metrics::Metrics> get_metrics()
  344. {
  345. return m_metrics;
  346. }
  347. // Try to grab an exclusive lock of the given realm path's lock file. If the lock
  348. // can be acquired, the callback will be executed with the lock and then return true.
  349. // Otherwise false will be returned directly.
  350. // The lock taken precludes races with other threads or processes accessing the
  351. // files through a DB.
  352. // It is safe to delete/replace realm files inside the callback.
  353. // WARNING: It is not safe to delete the lock file in the callback.
  354. using CallbackWithLock = util::FunctionRef<void(const std::string& realm_path)>;
  355. static bool call_with_lock(const std::string& realm_path, CallbackWithLock&& callback);
  356. enum CoreFileType : uint8_t {
  357. Lock,
  358. Storage,
  359. Management,
  360. Note,
  361. Log,
  362. };
  363. /// Get the path for the given type of file for a base Realm file path.
  364. /// \param realm_path The path for the main Realm file.
  365. /// \param type The type of associated file to get the path for.
  366. /// \return The base path with the appropriate type-specific suffix appended to it.
  367. static std::string get_core_file(const std::string& realm_path, CoreFileType type);
  368. /// Delete a Realm file and all associated control files.
  369. ///
  370. /// This function does not perform any locking and requires external
  371. /// synchronization to ensure that it is safe to call. If called within
  372. /// call_with_lock(), \p delete_lockfile must be false as the lockfile is not
  373. /// safe to delete while it is in use.
  374. ///
  375. /// \param base_path The Realm file to delete, which auxiliary file paths will be derived from.
  376. /// \param[out] did_delete_realm If non-null, will be set to true if the Realm file was deleted (even if a
  377. /// subsequent deletion failed)
  378. /// \param delete_lockfile By default the lock file is not deleted as it is unsafe to
  379. /// do so. If this is true, the lock file is deleted along with the other files.
  380. static void delete_files(const std::string& base_path, bool* did_delete_realm = nullptr,
  381. bool delete_lockfile = false);
  382. /// Mark this DB as the sync agent for the file.
  383. /// \throw MultipleSyncAgents if another DB is already the sync agent.
  384. void claim_sync_agent();
  385. void release_sync_agent();
  386. /// Returns true if there are threads waiting to acquire the write lock, false otherwise.
  387. /// To be used only when already holding the lock.
  388. bool other_writers_waiting_for_lock() const;
  389. protected:
  390. explicit DB(const DBOptions& options); // Is this ever used?
  391. private:
  392. class AsyncCommitHelper;
  393. class VersionManager;
  394. class EncryptionMarkerObserver;
  395. class FileVersionManager;
  396. class InMemoryVersionManager;
  397. struct SharedInfo;
  398. struct ReadCount;
  399. struct ReadLockInfo {
  400. enum Type { Frozen, Live, Full };
  401. uint_fast64_t m_version = std::numeric_limits<version_type>::max();
  402. uint_fast32_t m_reader_idx = 0;
  403. ref_type m_top_ref = 0;
  404. size_t m_file_size = 0;
  405. Type m_type = Live;
  406. // a little helper
  407. static std::unique_ptr<ReadLockInfo> make_fake(ref_type top_ref, size_t file_size)
  408. {
  409. auto res = std::make_unique<ReadLockInfo>();
  410. res->m_top_ref = top_ref;
  411. res->m_file_size = file_size;
  412. res->m_version = 1;
  413. return res;
  414. }
  415. void check() const noexcept
  416. {
  417. REALM_ASSERT_RELEASE_EX((m_top_ref & 7) == 0 && m_top_ref < m_file_size, m_version, m_reader_idx,
  418. m_top_ref, m_file_size);
  419. }
  420. };
  421. class ReadLockGuard;
  422. // Member variables
  423. mutable util::CheckedMutex m_mutex;
  424. int m_transaction_count GUARDED_BY(m_mutex) = 0;
  425. SlabAlloc m_alloc;
  426. std::unique_ptr<Replication> m_history;
  427. std::unique_ptr<VersionManager> m_version_manager;
  428. std::unique_ptr<EncryptionMarkerObserver> m_marker_observer;
  429. Replication* m_replication = nullptr;
  430. size_t m_free_space GUARDED_BY(m_mutex) = 0;
  431. size_t m_locked_space GUARDED_BY(m_mutex) = 0;
  432. size_t m_used_space GUARDED_BY(m_mutex) = 0;
  433. std::vector<ReadLockInfo> m_local_locks_held GUARDED_BY(m_mutex); // tracks all read locks held by this DB
  434. std::atomic<EvacStage> m_evac_stage = EvacStage::idle;
  435. util::File m_file;
  436. util::File::Map<SharedInfo> m_file_map; // Never remapped, provides access to everything but the ringbuffer
  437. std::unique_ptr<SharedInfo> m_in_memory_info;
  438. SharedInfo* m_info = nullptr;
  439. bool m_wait_for_change_enabled = true; // Initially wait_for_change is enabled
  440. bool m_write_transaction_open GUARDED_BY(m_mutex) = false;
  441. std::string m_db_path;
  442. size_t m_path_hash = 0;
  443. int m_file_format_version = 0;
  444. util::InterprocessMutex m_writemutex;
  445. std::unique_ptr<ReadLockInfo> m_fake_read_lock_if_immutable;
  446. util::InterprocessMutex m_controlmutex;
  447. util::InterprocessMutex m_versionlist_mutex;
  448. util::InterprocessCondVar m_new_commit_available;
  449. util::InterprocessCondVar m_pick_next_writer;
  450. std::function<void(int, int)> m_upgrade_callback;
  451. std::shared_ptr<metrics::Metrics> m_metrics;
  452. std::unique_ptr<AsyncCommitHelper> m_commit_helper;
  453. std::shared_ptr<util::Logger> m_logger;
  454. bool m_is_sync_agent = false;
  455. /// Attach this DB instance to the specified database file.
  456. ///
  457. /// While at least one instance of DB exists for a specific
  458. /// database file, a "lock" file will be present too. The lock file will be
  459. /// placed in the same directory as the database file, and its name will be
  460. /// derived by appending ".lock" to the name of the database file.
  461. ///
  462. /// When multiple DB instances refer to the same file, they must
  463. /// specify the same durability level, otherwise an exception will be
  464. /// thrown.
  465. ///
  466. /// \param file Filesystem path to a Realm database file.
  467. ///
  468. /// \param no_create If the database file does not already exist, it will be
  469. /// created (unless this is set to true.) When multiple threads are involved,
  470. /// it is safe to let the first thread, that gets to it, create the file.
  471. ///
  472. /// \param options See DBOptions for details of each option.
  473. /// Sensible defaults are provided if this parameter is left out.
  474. ///
  475. /// \throw FileAccessError If the file could not be opened. If the
  476. /// reason corresponds to one of the exception types that are derived from
  477. /// FileAccessError, the derived exception type is thrown. Note that
  478. /// InvalidDatabase is among these derived exception types.
  479. ///
  480. /// \throw FileFormatUpgradeRequired if \a DBOptions::allow_upgrade
  481. /// is `false` and an upgrade is required.
  482. ///
  483. /// \throw LogicError if both DBOptions::allow_upgrade and is_immutable is true.
  484. /// \throw UnsupportedFileFormatVersion if the file format version or
  485. /// history schema version is one which this version of Realm does not know
  486. /// how to migrate from.
  487. void open(const std::string& file, bool no_create = false, const DBOptions& options = DBOptions())
  488. REQUIRES(!m_mutex);
  489. void open(BinaryData, bool take_ownership = true) REQUIRES(!m_mutex);
  490. void open(Replication&, const std::string& file, const DBOptions& options = DBOptions()) REQUIRES(!m_mutex);
  491. void open(Replication& repl, const DBOptions options = DBOptions()) REQUIRES(!m_mutex);
  492. void do_open(const std::string& file, bool no_create, const DBOptions& options);
  493. Replication* const* get_repl() const noexcept
  494. {
  495. return &m_replication;
  496. }
  497. // Ring buffer management
  498. bool ringbuf_is_empty() const noexcept;
  499. size_t ringbuf_size() const noexcept;
  500. size_t ringbuf_capacity() const noexcept;
  501. bool ringbuf_is_first(size_t ndx) const noexcept;
  502. void ringbuf_remove_first() noexcept;
  503. size_t ringbuf_find(uint64_t version) const noexcept;
  504. ReadCount& ringbuf_get(size_t ndx) noexcept;
  505. ReadCount& ringbuf_get_first() noexcept;
  506. ReadCount& ringbuf_get_last() noexcept;
  507. void ringbuf_put(const ReadCount& v);
  508. void ringbuf_expand();
  509. /// Grab a read lock on the snapshot associated with the specified
  510. /// version. If `version_id == VersionID()`, a read lock will be grabbed on
  511. /// the latest available snapshot. Fails if the snapshot is no longer
  512. /// available.
  513. ///
  514. /// As a side effect update memory mapping to ensure that the ringbuffer
  515. /// entries referenced in the readlock info is accessible.
  516. ReadLockInfo grab_read_lock(ReadLockInfo::Type, VersionID) REQUIRES(!m_mutex);
  517. // Release a specific read lock. The read lock MUST have been obtained by a
  518. // call to grab_read_lock().
  519. void release_read_lock(ReadLockInfo&) noexcept REQUIRES(!m_mutex);
  520. void do_release_read_lock(ReadLockInfo&) noexcept REQUIRES(m_mutex);
  521. // Stop tracking a read lock without actually releasing it.
  522. void leak_read_lock(ReadLockInfo&) noexcept REQUIRES(!m_mutex);
  523. // Release all read locks held by this DB object. After release, further calls to
  524. // release_read_lock for locks already released must be avoided.
  525. void release_all_read_locks() noexcept REQUIRES(!m_mutex);
  526. /// return true if write transaction can commence, false otherwise.
  527. bool do_try_begin_write() REQUIRES(!m_mutex);
  528. void do_begin_write() REQUIRES(!m_mutex);
  529. void do_begin_possibly_async_write() REQUIRES(!m_mutex);
  530. version_type do_commit(Transaction&, bool commit_to_disk = true) REQUIRES(!m_mutex);
  531. void do_end_write() noexcept REQUIRES(!m_mutex);
  532. void end_write_on_correct_thread() noexcept REQUIRES(!m_mutex);
  533. // Must be called only by someone that has a lock on the write mutex.
  534. void low_level_commit(uint_fast64_t new_version, Transaction& transaction, bool commit_to_disk = true)
  535. REQUIRES(!m_mutex);
  536. void do_async_commits();
  537. /// Upgrade file format and/or history schema
  538. void upgrade_file_format(bool allow_file_format_upgrade, int target_file_format_version,
  539. int current_hist_schema_version, int target_hist_schema_version) REQUIRES(!m_mutex);
  540. int get_file_format_version() const noexcept;
  541. /// finish up the process of starting a write transaction. Internal use only.
  542. void finish_begin_write() REQUIRES(!m_mutex);
  543. void reset_free_space_tracking()
  544. {
  545. m_alloc.reset_free_space_tracking();
  546. }
  547. void close_internal(std::unique_lock<util::InterprocessMutex>, bool allow_open_read_transactions)
  548. REQUIRES(!m_mutex);
  549. void async_begin_write(util::UniqueFunction<void()> fn);
  550. void async_end_write();
  551. void async_sync_to_disk(util::UniqueFunction<void()> fn);
  552. friend class SlabAlloc;
  553. friend class Transaction;
  554. };
  555. inline void DB::get_stats(size_t& free_space, size_t& used_space, size_t* locked_space) const
  556. {
  557. util::CheckedLockGuard lock(m_mutex);
  558. free_space = m_free_space;
  559. used_space = m_used_space;
  560. if (locked_space) {
  561. *locked_space = m_locked_space;
  562. }
  563. }
  564. class DisableReplication {
  565. public:
  566. DisableReplication(Transaction& t);
  567. ~DisableReplication();
  568. private:
  569. Transaction& m_tr;
  570. DBRef m_owner;
  571. Replication* m_repl;
  572. DB::version_type m_version;
  573. };
  574. // Implementation:
  575. struct DB::BadVersion : Exception {
  576. BadVersion(version_type version)
  577. : Exception(ErrorCodes::BadVersion,
  578. util::format("Unable to lock version %1 as it does not exist or has been cleaned up.", version))
  579. {
  580. }
  581. };
  582. inline bool DB::is_attached() const noexcept
  583. {
  584. return bool(m_fake_read_lock_if_immutable) || m_info;
  585. }
  586. class DB::ReadLockGuard {
  587. public:
  588. ReadLockGuard(DB& shared_group, ReadLockInfo& read_lock) noexcept
  589. : m_db(shared_group)
  590. , m_read_lock(&read_lock)
  591. {
  592. }
  593. ~ReadLockGuard() noexcept
  594. {
  595. if (m_read_lock)
  596. m_db.release_read_lock(*m_read_lock);
  597. }
  598. void release() noexcept
  599. {
  600. m_read_lock = 0;
  601. }
  602. private:
  603. DB& m_db;
  604. ReadLockInfo* m_read_lock;
  605. };
  606. inline int DB::get_file_format_version() const noexcept
  607. {
  608. return m_file_format_version;
  609. }
  610. } // namespace realm
  611. #endif // REALM_DB_HPP