replication.hpp 20 KB

123456789101112131415161718192021222324252627282930313233343536373839404142434445464748495051525354555657585960616263646566676869707172737475767778798081828384858687888990919293949596979899100101102103104105106107108109110111112113114115116117118119120121122123124125126127128129130131132133134135136137138139140141142143144145146147148149150151152153154155156157158159160161162163164165166167168169170171172173174175176177178179180181182183184185186187188189190191192193194195196197198199200201202203204205206207208209210211212213214215216217218219220221222223224225226227228229230231232233234235236237238239240241242243244245246247248249250251252253254255256257258259260261262263264265266267268269270271272273274275276277278279280281282283284285286287288289290291292293294295296297298299300301302303304305306307308309310311312313314315316317318319320321322323324325326327328329330331332333334335336337338339340341342343344345346347348349350351352353354355356357358359360361362363364365366367368369370371372373374375376377378379380381382383384385386387388389390391392393394395396397398399400401402403404405406407408409410411412413414415416417418419420421422423424425426427428429430431432433434435436437438439440441442443444445446447448449450451452453454455456457458459460461462463464465466467468469470471472473474475476477478
  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_REPLICATION_HPP
  19. #define REALM_REPLICATION_HPP
  20. #include <algorithm>
  21. #include <limits>
  22. #include <memory>
  23. #include <exception>
  24. #include <string>
  25. #include <realm/util/assert.hpp>
  26. #include <realm/util/safe_int_ops.hpp>
  27. #include <realm/util/buffer.hpp>
  28. #include <realm/util/string_buffer.hpp>
  29. #include <realm/impl/cont_transact_hist.hpp>
  30. #include <realm/impl/transact_log.hpp>
  31. namespace realm {
  32. namespace util {
  33. class Logger;
  34. }
  35. // FIXME: Be careful about the possibility of one modification function being called by another where both do
  36. // transaction logging.
  37. /// Replication is enabled by passing an instance of an implementation of this
  38. /// class to the DB constructor.
  39. class Replication : public _impl::TransactLogConvenientEncoder {
  40. public:
  41. // Be sure to keep this type aligned with what is actually used in DB.
  42. using version_type = _impl::History::version_type;
  43. using InputStream = _impl::NoCopyInputStream;
  44. class TransactLogApplier;
  45. class Interrupted; // Exception
  46. class SimpleIndexTranslator;
  47. virtual std::string get_database_path() const = 0;
  48. /// Called during construction of the associated DB object.
  49. ///
  50. /// \param db The associated DB object.
  51. virtual void initialize(DB& db) = 0;
  52. /// Called by the associated DB object when a session is
  53. /// initiated. A *session* is a sequence of temporally overlapping
  54. /// accesses to a specific Realm file, where each access consists of a
  55. /// DB object through which the Realm file is open. Session
  56. /// initiation occurs during the first opening of the Realm file within such
  57. /// a session.
  58. ///
  59. /// Session initiation fails if this function throws.
  60. ///
  61. /// \param version The current version of the associated Realm.
  62. ///
  63. /// The default implementation does nothing.
  64. virtual void initiate_session(version_type version) = 0;
  65. /// Called by the associated DB object when a session is
  66. /// terminated. See initiate_session() for the definition of a
  67. /// session. Session termination occurs upon closing the Realm through the
  68. /// last DB object within the session.
  69. ///
  70. /// The default implementation does nothing.
  71. virtual void terminate_session() noexcept = 0;
  72. /// \defgroup replication_transactions
  73. //@{
  74. /// From the point of view of the Replication class, a transaction is
  75. /// initiated when, and only when the associated Transaction object calls
  76. /// initiate_transact() and the call is successful. The associated
  77. /// Transaction object must terminate every initiated transaction either by
  78. /// calling finalize_commit() or by calling abort_transact(). It may only
  79. /// call finalize_commit(), however, after calling prepare_commit(), and
  80. /// only when prepare_commit() succeeds. If prepare_commit() fails (i.e.,
  81. /// throws) abort_transact() must still be called.
  82. ///
  83. /// The associated Transaction object is supposed to terminate a transaction
  84. /// as soon as possible, and is required to terminate it before attempting
  85. /// to initiate a new one.
  86. ///
  87. /// initiate_transact() is called by the associated Transaction object as
  88. /// part of the initiation of a transaction, and at a time where the caller
  89. /// has acquired exclusive write access to the local Realm. The Replication
  90. /// implementation is allowed to perform "precursor transactions" on the
  91. /// local Realm at this time. During the initiated transaction, the
  92. /// associated DB object must inform the Replication object of all
  93. /// modifying operations by calling set_value() and friends.
  94. ///
  95. /// FIXME: There is currently no way for implementations to perform
  96. /// precursor transactions, since a regular transaction would cause a dead
  97. /// lock when it tries to acquire a write lock. Consider giving access to
  98. /// special non-locking precursor transactions via an extra argument to this
  99. /// function.
  100. ///
  101. /// prepare_commit() serves as the first phase of a two-phase commit. This
  102. /// function is called by the associated Transaction object immediately
  103. /// before the commit operation on the local Realm. The associated
  104. /// Transaction object will then, as the second phase, either call
  105. /// finalize_commit() or abort_transact() depending on whether the commit
  106. /// operation succeeded or not. The Replication implementation is allowed to
  107. /// modify the Realm via the associated Transaction object at this time
  108. /// (important to in-Realm histories).
  109. ///
  110. /// initiate_transact() and prepare_commit() are allowed to block the
  111. /// calling thread if, for example, they need to communicate over the
  112. /// network. If a calling thread is blocked in one of these functions, it
  113. /// must be possible to interrupt the blocking operation by having another
  114. /// thread call interrupt(). The contract is as follows: When interrupt() is
  115. /// called, then any execution of initiate_transact() or prepare_commit(),
  116. /// initiated before the interruption, must complete without blocking, or
  117. /// the execution must be aborted by throwing an Interrupted exception. If
  118. /// initiate_transact() or prepare_commit() throws Interrupted, it counts as
  119. /// a failed operation.
  120. ///
  121. /// finalize_commit() is called by the associated Transaction object
  122. /// immediately after a successful commit operation on the local Realm. This
  123. /// happens at a time where modification of the Realm is no longer possible
  124. /// via the associated Transaction object. In the case of in-Realm
  125. /// histories, the changes are automatically finalized as part of the commit
  126. /// operation performed by the caller prior to the invocation of
  127. /// finalize_commit(), so in that case, finalize_commit() might not need to
  128. /// do anything.
  129. ///
  130. /// abort_transact() is called by the associated Transaction object to
  131. /// terminate a transaction without committing. That is, any transaction
  132. /// that is not terminated by finalize_commit() is terminated by
  133. /// abort_transact(). This could be due to an explicit rollback, or due to a
  134. /// failed commit attempt.
  135. ///
  136. /// Note that finalize_commit() and abort_transact() are not allowed to
  137. /// throw.
  138. ///
  139. /// \param current_version The version of the snapshot that the current
  140. /// transaction is based on.
  141. ///
  142. /// \param history_updated Pass true only when the history has already been
  143. /// updated to reflect the currently bound snapshot, such as when
  144. /// _impl::History::update_early_from_top_ref() was called during the
  145. /// transition from a read transaction to the current write transaction.
  146. ///
  147. /// \throw Interrupted Thrown by initiate_transact() and prepare_commit() if
  148. /// a blocking operation was interrupted.
  149. void initiate_transact(Group& group, version_type current_version, bool history_updated);
  150. /// \param current_version The version of the snapshot that the current
  151. /// transaction is based on.
  152. /// \return prepare_commit() returns the version of the new snapshot
  153. /// produced by the transaction.
  154. version_type prepare_commit(version_type current_version);
  155. void finalize_commit() noexcept;
  156. void abort_transact() noexcept;
  157. //@}
  158. /// Get the list of uncommitted changes accumulated so far in the current
  159. /// write transaction.
  160. ///
  161. /// The callee retains ownership of the referenced memory. The ownership is
  162. /// not handed over to the caller.
  163. ///
  164. /// This function may be called only during a write transaction (prior to
  165. /// initiation of commit operation). In that case, the caller may assume that the
  166. /// returned memory reference stays valid for the remainder of the transaction (up
  167. /// until initiation of the commit operation).
  168. virtual BinaryData get_uncommitted_changes() const noexcept = 0;
  169. /// Interrupt any blocking call to a function in this class. This function
  170. /// may be called asyncronously from any thread, but it may not be called
  171. /// from a system signal handler.
  172. ///
  173. /// Some of the public function members of this class may block, but only
  174. /// when it it is explicitely stated in the documention for those functions.
  175. ///
  176. /// FIXME: Currently we do not state blocking behaviour for all the
  177. /// functions that can block.
  178. ///
  179. /// After any function has returned with an interruption indication, the
  180. /// only functions that may safely be called are abort_transact() and the
  181. /// destructor. If a client, after having received an interruption
  182. /// indication, calls abort_transact() and then clear_interrupt(), it may
  183. /// resume normal operation through this Replication object.
  184. void interrupt() noexcept;
  185. /// May be called by a client to reset this Replication object after an
  186. /// interrupted transaction. It is not an error to call this function in a
  187. /// situation where no interruption has occured.
  188. void clear_interrupt() noexcept;
  189. /// CAUTION: These values are stored in Realm files, so value reassignment
  190. /// is not allowed.
  191. enum HistoryType {
  192. /// No history available. No support for either continuous transactions
  193. /// or inter-client synchronization.
  194. hist_None = 0,
  195. /// Out-of-Realm history supporting continuous transactions.
  196. ///
  197. /// NOTE: This history type is no longer in use. The value needs to stay
  198. /// reserved in case someone tries to open an old Realm file.
  199. hist_OutOfRealm = 1,
  200. /// In-Realm history supporting continuous transactions
  201. /// (make_in_realm_history()).
  202. hist_InRealm = 2,
  203. /// In-Realm history supporting continuous transactions and client-side
  204. /// synchronization protocol (realm::sync::ClientHistory).
  205. hist_SyncClient = 3,
  206. /// In-Realm history supporting continuous transactions and server-side
  207. /// synchronization protocol (realm::_impl::ServerHistory).
  208. hist_SyncServer = 4
  209. };
  210. /// Returns the type of history maintained by this Replication
  211. /// implementation, or \ref hist_None if no history is maintained by it.
  212. ///
  213. /// This type is used to ensure that all session participants agree on
  214. /// history type, and that the Realm file contains a compatible type of
  215. /// history, at the beginning of a new session.
  216. ///
  217. /// As a special case, if there is no top array (Group::m_top) at the
  218. /// beginning of a new session, then the history type is still undecided and
  219. /// all history types (as returned by get_history_type()) are threfore
  220. /// allowed for the session initiator. Note that this case only arises if
  221. /// there was no preceding session, or if no transaction was sucessfully
  222. /// committed during any of the preceding sessions. As soon as a transaction
  223. /// is successfully committed, the Realm contains at least a top array, and
  224. /// from that point on, the history type is generally fixed, although still
  225. /// subject to certain allowed changes (as mentioned below).
  226. ///
  227. /// For the sake of backwards compatibility with older Realm files that does
  228. /// not store any history type, the following rule shall apply:
  229. ///
  230. /// - If the top array of a Realm file (Group::m_top) does not contain a
  231. /// history type, because it is too short, it shall be understood as
  232. /// implicitly storing the type \ref hist_None.
  233. ///
  234. /// Note: In what follows, the meaning of *preceding session* is: The last
  235. /// preceding session that modified the Realm by sucessfully committing a
  236. /// new snapshot.
  237. ///
  238. /// It shall be allowed to switch to a \ref hist_InRealm history if the
  239. /// stored history type is \ref hist_None. This can be done simply by adding
  240. /// a new history to the Realm file. This is possible because histories of
  241. /// this type a transient in nature, and need not survive from one session
  242. /// to the next.
  243. ///
  244. /// On the other hand, as soon as a history of type \ref hist_InRealm is
  245. /// added to a Realm file, that history type is binding for all subsequent
  246. /// sessions. In theory, this constraint is not necessary, and a later
  247. /// switch to \ref hist_None would be possible because of the transient
  248. /// nature of it, however, because the \ref hist_InRealm history remains in
  249. /// the Realm file, there are practical complications, and for that reason,
  250. /// such switching shall not be supported.
  251. ///
  252. /// The \ref hist_SyncClient history type can only be used if the stored
  253. /// history type is also \ref hist_SyncClient, or when there is no top array
  254. /// yet. Likewise, the \ref hist_SyncServer history type can only be used if
  255. /// the stored history type is also \ref hist_SyncServer, or when there is
  256. /// no top array yet. Additionally, when the stored history type is \ref
  257. /// hist_SyncClient or \ref hist_SyncServer, then all subsequent sessions
  258. /// must have the same type. These restrictions apply because such a history
  259. /// needs to be maintained persistently across sessions.
  260. ///
  261. /// In general, if there is no stored history type (no top array) at the
  262. /// beginning of a new session, or if the stored type disagrees with what is
  263. /// returned by get_history_type() (which is possible due to particular
  264. /// allowed changes of history type), the actual history type (as returned
  265. /// by get_history_type()) used during that session, must be stored in the
  266. /// Realm during the first successfully committed transaction in that
  267. /// session. But note that there is still no need to expand the top array to
  268. /// store the history type \ref hist_None, due to the rule mentioned above.
  269. ///
  270. /// This function must return \ref hist_None when, and only when
  271. /// get_history() returns null.
  272. virtual HistoryType get_history_type() const noexcept = 0;
  273. /// Returns the schema version of the history maintained by this Replication
  274. /// implementation, or 0 if no history is maintained by it. All session
  275. /// participants must agree on history schema version.
  276. ///
  277. /// Must return 0 if get_history_type() returns \ref hist_None.
  278. virtual int get_history_schema_version() const noexcept = 0;
  279. /// Implementation may assume that this function is only ever called with a
  280. /// stored schema version that is less than what was returned by
  281. /// get_history_schema_version().
  282. virtual bool is_upgradable_history_schema(int stored_schema_version) const noexcept = 0;
  283. /// The implementation may assume that this function is only ever called if
  284. /// is_upgradable_history_schema() was called with the same stored schema
  285. /// version, and returned true. This implies that the specified stored
  286. /// schema version is always strictly less than what was returned by
  287. /// get_history_schema_version().
  288. virtual void upgrade_history_schema(int stored_schema_version) = 0;
  289. /// Returns an object that gives access to the history of changesets
  290. /// used by writers. All writers can share the same object as all write
  291. /// transactions are serialized.
  292. ///
  293. /// This function must return null when, and only when get_history_type()
  294. /// returns \ref hist_None.
  295. virtual _impl::History* _get_history_write() = 0;
  296. /// Returns an object that gives access to the history of changesets in a
  297. /// way that allows for continuous transactions to work. All readers must
  298. /// get their own exclusive object as readers are not blocking each other.
  299. /// (Group::advance_transact() in particular).
  300. ///
  301. /// This function must return null when, and only when get_history_type()
  302. /// returns \ref hist_None.
  303. virtual std::unique_ptr<_impl::History> _create_history_read() = 0;
  304. ~Replication() override;
  305. protected:
  306. DB* m_db = nullptr;
  307. Replication(_impl::TransactLogStream& stream);
  308. void register_db(DB* owner)
  309. {
  310. m_db = owner;
  311. }
  312. //@{
  313. /// do_initiate_transact() is called by initiate_transact(), and likewise
  314. /// for do_prepare_commit), do_finalize_commit(), and do_abort_transact().
  315. ///
  316. /// With respect to exception safety, the Replication implementation has two
  317. /// options: It can prepare to accept the accumulated changeset in
  318. /// do_prepapre_commit() by allocating all required resources, and delay the
  319. /// actual acceptance to do_finalize_commit(), which requires that the final
  320. /// acceptance can be done without any risk of failure. Alternatively, the
  321. /// Replication implementation can fully accept the changeset in
  322. /// do_prepapre_commit() (allowing for failure), and then discard that
  323. /// changeset during the next invocation of do_initiate_transact() if
  324. /// `current_version` indicates that the previous transaction failed.
  325. virtual void do_initiate_transact(Group& group, version_type current_version, bool history_updated) = 0;
  326. virtual version_type do_prepare_commit(version_type orig_version) = 0;
  327. virtual void do_finalize_commit() noexcept = 0;
  328. virtual void do_abort_transact() noexcept = 0;
  329. //@}
  330. virtual void do_interrupt() noexcept = 0;
  331. virtual void do_clear_interrupt() noexcept = 0;
  332. friend class _impl::TransactReverser;
  333. friend class DB;
  334. };
  335. class Replication::Interrupted : public std::exception {
  336. public:
  337. const char* what() const noexcept override
  338. {
  339. return "Interrupted";
  340. }
  341. };
  342. class TrivialReplication : public Replication {
  343. public:
  344. ~TrivialReplication() noexcept {}
  345. std::string get_database_path() const override;
  346. protected:
  347. typedef Replication::version_type version_type;
  348. TrivialReplication(const std::string& database_file);
  349. virtual version_type prepare_changeset(const char* data, size_t size, version_type orig_version) = 0;
  350. virtual void finalize_changeset() noexcept = 0;
  351. BinaryData get_uncommitted_changes() const noexcept override;
  352. void initialize(DB&) override;
  353. void do_initiate_transact(Group& group, version_type, bool) override;
  354. version_type do_prepare_commit(version_type orig_version) override;
  355. void do_finalize_commit() noexcept override;
  356. void do_abort_transact() noexcept override;
  357. void do_interrupt() noexcept override;
  358. void do_clear_interrupt() noexcept override;
  359. private:
  360. const std::string m_database_file;
  361. _impl::TransactLogBufferStream m_stream;
  362. size_t transact_log_size();
  363. };
  364. // Implementation:
  365. inline Replication::Replication(_impl::TransactLogStream& stream)
  366. : _impl::TransactLogConvenientEncoder(stream)
  367. {
  368. }
  369. inline void Replication::initiate_transact(Group& group, version_type current_version, bool history_updated)
  370. {
  371. if (auto hist = _get_history_write()) {
  372. hist->set_group(&group, history_updated);
  373. }
  374. do_initiate_transact(group, current_version, history_updated);
  375. reset_selection_caches();
  376. }
  377. inline Replication::version_type Replication::prepare_commit(version_type orig_version)
  378. {
  379. return do_prepare_commit(orig_version);
  380. }
  381. inline void Replication::finalize_commit() noexcept
  382. {
  383. do_finalize_commit();
  384. }
  385. inline void Replication::abort_transact() noexcept
  386. {
  387. do_abort_transact();
  388. }
  389. inline void Replication::interrupt() noexcept
  390. {
  391. do_interrupt();
  392. }
  393. inline void Replication::clear_interrupt() noexcept
  394. {
  395. do_clear_interrupt();
  396. }
  397. inline TrivialReplication::TrivialReplication(const std::string& database_file)
  398. : Replication(m_stream)
  399. , m_database_file(database_file)
  400. {
  401. }
  402. inline BinaryData TrivialReplication::get_uncommitted_changes() const noexcept
  403. {
  404. const char* data = m_stream.get_data();
  405. size_t size = write_position() - data;
  406. return BinaryData(data, size);
  407. }
  408. inline size_t TrivialReplication::transact_log_size()
  409. {
  410. return write_position() - m_stream.get_data();
  411. }
  412. } // namespace realm
  413. #endif // REALM_REPLICATION_HPP