xfs_log_priv.h 22 KB

123456789101112131415161718192021222324252627282930313233343536373839404142434445464748495051525354555657585960616263646566676869707172737475767778798081828384858687888990919293949596979899100101102103104105106107108109110111112113114115116117118119120121122123124125126127128129130131132133134135136137138139140141142143144145146147148149150151152153154155156157158159160161162163164165166167168169170171172173174175176177178179180181182183184185186187188189190191192193194195196197198199200201202203204205206207208209210211212213214215216217218219220221222223224225226227228229230231232233234235236237238239240241242243244245246247248249250251252253254255256257258259260261262263264265266267268269270271272273274275276277278279280281282283284285286287288289290291292293294295296297298299300301302303304305306307308309310311312313314315316317318319320321322323324325326327328329330331332333334335336337338339340341342343344345346347348349350351352353354355356357358359360361362363364365366367368369370371372373374375376377378379380381382383384385386387388389390391392393394395396397398399400401402403404405406407408409410411412413414415416417418419420421422423424425426427428429430431432433434435436437438439440441442443444445446447448449450451452453454455456457458459460461462463464465466467468469470471472473474475476477478479480481482483484485486487488489490491492493494495496497498499500501502503504505506507508509510511512513514515516517518519520521522523524525526527528529530531532533534535536537538539540541542543544545546547548549550551552553554555556557558559560561562563564565566567568569570571572573574575576577578579580581582583584585586587588589590591592593594595596597598599600601602603604605606607608
  1. // SPDX-License-Identifier: GPL-2.0
  2. /*
  3. * Copyright (c) 2000-2003,2005 Silicon Graphics, Inc.
  4. * All Rights Reserved.
  5. */
  6. #ifndef __XFS_LOG_PRIV_H__
  7. #define __XFS_LOG_PRIV_H__
  8. struct xfs_buf;
  9. struct xlog;
  10. struct xlog_ticket;
  11. struct xfs_mount;
  12. struct xfs_log_callback;
  13. /*
  14. * Flags for log structure
  15. */
  16. #define XLOG_ACTIVE_RECOVERY 0x2 /* in the middle of recovery */
  17. #define XLOG_RECOVERY_NEEDED 0x4 /* log was recovered */
  18. #define XLOG_IO_ERROR 0x8 /* log hit an I/O error, and being
  19. shutdown */
  20. #define XLOG_TAIL_WARN 0x10 /* log tail verify warning issued */
  21. /*
  22. * get client id from packed copy.
  23. *
  24. * this hack is here because the xlog_pack code copies four bytes
  25. * of xlog_op_header containing the fields oh_clientid, oh_flags
  26. * and oh_res2 into the packed copy.
  27. *
  28. * later on this four byte chunk is treated as an int and the
  29. * client id is pulled out.
  30. *
  31. * this has endian issues, of course.
  32. */
  33. static inline uint xlog_get_client_id(__be32 i)
  34. {
  35. return be32_to_cpu(i) >> 24;
  36. }
  37. /*
  38. * In core log state
  39. */
  40. #define XLOG_STATE_ACTIVE 0x0001 /* Current IC log being written to */
  41. #define XLOG_STATE_WANT_SYNC 0x0002 /* Want to sync this iclog; no more writes */
  42. #define XLOG_STATE_SYNCING 0x0004 /* This IC log is syncing */
  43. #define XLOG_STATE_DONE_SYNC 0x0008 /* Done syncing to disk */
  44. #define XLOG_STATE_DO_CALLBACK \
  45. 0x0010 /* Process callback functions */
  46. #define XLOG_STATE_CALLBACK 0x0020 /* Callback functions now */
  47. #define XLOG_STATE_DIRTY 0x0040 /* Dirty IC log, not ready for ACTIVE status*/
  48. #define XLOG_STATE_IOERROR 0x0080 /* IO error happened in sync'ing log */
  49. #define XLOG_STATE_IOABORT 0x0100 /* force abort on I/O completion (debug) */
  50. #define XLOG_STATE_ALL 0x7FFF /* All possible valid flags */
  51. #define XLOG_STATE_NOTUSED 0x8000 /* This IC log not being used */
  52. /*
  53. * Flags to log ticket
  54. */
  55. #define XLOG_TIC_INITED 0x1 /* has been initialized */
  56. #define XLOG_TIC_PERM_RESERV 0x2 /* permanent reservation */
  57. #define XLOG_TIC_FLAGS \
  58. { XLOG_TIC_INITED, "XLOG_TIC_INITED" }, \
  59. { XLOG_TIC_PERM_RESERV, "XLOG_TIC_PERM_RESERV" }
  60. /*
  61. * Below are states for covering allocation transactions.
  62. * By covering, we mean changing the h_tail_lsn in the last on-disk
  63. * log write such that no allocation transactions will be re-done during
  64. * recovery after a system crash. Recovery starts at the last on-disk
  65. * log write.
  66. *
  67. * These states are used to insert dummy log entries to cover
  68. * space allocation transactions which can undo non-transactional changes
  69. * after a crash. Writes to a file with space
  70. * already allocated do not result in any transactions. Allocations
  71. * might include space beyond the EOF. So if we just push the EOF a
  72. * little, the last transaction for the file could contain the wrong
  73. * size. If there is no file system activity, after an allocation
  74. * transaction, and the system crashes, the allocation transaction
  75. * will get replayed and the file will be truncated. This could
  76. * be hours/days/... after the allocation occurred.
  77. *
  78. * The fix for this is to do two dummy transactions when the
  79. * system is idle. We need two dummy transaction because the h_tail_lsn
  80. * in the log record header needs to point beyond the last possible
  81. * non-dummy transaction. The first dummy changes the h_tail_lsn to
  82. * the first transaction before the dummy. The second dummy causes
  83. * h_tail_lsn to point to the first dummy. Recovery starts at h_tail_lsn.
  84. *
  85. * These dummy transactions get committed when everything
  86. * is idle (after there has been some activity).
  87. *
  88. * There are 5 states used to control this.
  89. *
  90. * IDLE -- no logging has been done on the file system or
  91. * we are done covering previous transactions.
  92. * NEED -- logging has occurred and we need a dummy transaction
  93. * when the log becomes idle.
  94. * DONE -- we were in the NEED state and have committed a dummy
  95. * transaction.
  96. * NEED2 -- we detected that a dummy transaction has gone to the
  97. * on disk log with no other transactions.
  98. * DONE2 -- we committed a dummy transaction when in the NEED2 state.
  99. *
  100. * There are two places where we switch states:
  101. *
  102. * 1.) In xfs_sync, when we detect an idle log and are in NEED or NEED2.
  103. * We commit the dummy transaction and switch to DONE or DONE2,
  104. * respectively. In all other states, we don't do anything.
  105. *
  106. * 2.) When we finish writing the on-disk log (xlog_state_clean_log).
  107. *
  108. * No matter what state we are in, if this isn't the dummy
  109. * transaction going out, the next state is NEED.
  110. * So, if we aren't in the DONE or DONE2 states, the next state
  111. * is NEED. We can't be finishing a write of the dummy record
  112. * unless it was committed and the state switched to DONE or DONE2.
  113. *
  114. * If we are in the DONE state and this was a write of the
  115. * dummy transaction, we move to NEED2.
  116. *
  117. * If we are in the DONE2 state and this was a write of the
  118. * dummy transaction, we move to IDLE.
  119. *
  120. *
  121. * Writing only one dummy transaction can get appended to
  122. * one file space allocation. When this happens, the log recovery
  123. * code replays the space allocation and a file could be truncated.
  124. * This is why we have the NEED2 and DONE2 states before going idle.
  125. */
  126. #define XLOG_STATE_COVER_IDLE 0
  127. #define XLOG_STATE_COVER_NEED 1
  128. #define XLOG_STATE_COVER_DONE 2
  129. #define XLOG_STATE_COVER_NEED2 3
  130. #define XLOG_STATE_COVER_DONE2 4
  131. #define XLOG_COVER_OPS 5
  132. /* Ticket reservation region accounting */
  133. #define XLOG_TIC_LEN_MAX 15
  134. /*
  135. * Reservation region
  136. * As would be stored in xfs_log_iovec but without the i_addr which
  137. * we don't care about.
  138. */
  139. typedef struct xlog_res {
  140. uint r_len; /* region length :4 */
  141. uint r_type; /* region's transaction type :4 */
  142. } xlog_res_t;
  143. typedef struct xlog_ticket {
  144. struct list_head t_queue; /* reserve/write queue */
  145. struct task_struct *t_task; /* task that owns this ticket */
  146. xlog_tid_t t_tid; /* transaction identifier : 4 */
  147. atomic_t t_ref; /* ticket reference count : 4 */
  148. int t_curr_res; /* current reservation in bytes : 4 */
  149. int t_unit_res; /* unit reservation in bytes : 4 */
  150. char t_ocnt; /* original count : 1 */
  151. char t_cnt; /* current count : 1 */
  152. char t_clientid; /* who does this belong to; : 1 */
  153. char t_flags; /* properties of reservation : 1 */
  154. /* reservation array fields */
  155. uint t_res_num; /* num in array : 4 */
  156. uint t_res_num_ophdrs; /* num op hdrs : 4 */
  157. uint t_res_arr_sum; /* array sum : 4 */
  158. uint t_res_o_flow; /* sum overflow : 4 */
  159. xlog_res_t t_res_arr[XLOG_TIC_LEN_MAX]; /* array of res : 8 * 15 */
  160. } xlog_ticket_t;
  161. /*
  162. * - A log record header is 512 bytes. There is plenty of room to grow the
  163. * xlog_rec_header_t into the reserved space.
  164. * - ic_data follows, so a write to disk can start at the beginning of
  165. * the iclog.
  166. * - ic_forcewait is used to implement synchronous forcing of the iclog to disk.
  167. * - ic_next is the pointer to the next iclog in the ring.
  168. * - ic_bp is a pointer to the buffer used to write this incore log to disk.
  169. * - ic_log is a pointer back to the global log structure.
  170. * - ic_callback is a linked list of callback function/argument pairs to be
  171. * called after an iclog finishes writing.
  172. * - ic_size is the full size of the header plus data.
  173. * - ic_offset is the current number of bytes written to in this iclog.
  174. * - ic_refcnt is bumped when someone is writing to the log.
  175. * - ic_state is the state of the iclog.
  176. *
  177. * Because of cacheline contention on large machines, we need to separate
  178. * various resources onto different cachelines. To start with, make the
  179. * structure cacheline aligned. The following fields can be contended on
  180. * by independent processes:
  181. *
  182. * - ic_callback_*
  183. * - ic_refcnt
  184. * - fields protected by the global l_icloglock
  185. *
  186. * so we need to ensure that these fields are located in separate cachelines.
  187. * We'll put all the read-only and l_icloglock fields in the first cacheline,
  188. * and move everything else out to subsequent cachelines.
  189. */
  190. typedef struct xlog_in_core {
  191. wait_queue_head_t ic_force_wait;
  192. wait_queue_head_t ic_write_wait;
  193. struct xlog_in_core *ic_next;
  194. struct xlog_in_core *ic_prev;
  195. struct xfs_buf *ic_bp;
  196. struct xlog *ic_log;
  197. int ic_size;
  198. int ic_offset;
  199. int ic_bwritecnt;
  200. unsigned short ic_state;
  201. char *ic_datap; /* pointer to iclog data */
  202. /* Callback structures need their own cacheline */
  203. spinlock_t ic_callback_lock ____cacheline_aligned_in_smp;
  204. struct xfs_log_callback *ic_callback;
  205. struct xfs_log_callback **ic_callback_tail;
  206. /* reference counts need their own cacheline */
  207. atomic_t ic_refcnt ____cacheline_aligned_in_smp;
  208. xlog_in_core_2_t *ic_data;
  209. #define ic_header ic_data->hic_header
  210. } xlog_in_core_t;
  211. /*
  212. * The CIL context is used to aggregate per-transaction details as well be
  213. * passed to the iclog for checkpoint post-commit processing. After being
  214. * passed to the iclog, another context needs to be allocated for tracking the
  215. * next set of transactions to be aggregated into a checkpoint.
  216. */
  217. struct xfs_cil;
  218. struct xfs_cil_ctx {
  219. struct xfs_cil *cil;
  220. xfs_lsn_t sequence; /* chkpt sequence # */
  221. xfs_lsn_t start_lsn; /* first LSN of chkpt commit */
  222. xfs_lsn_t commit_lsn; /* chkpt commit record lsn */
  223. struct xlog_ticket *ticket; /* chkpt ticket */
  224. int nvecs; /* number of regions */
  225. int space_used; /* aggregate size of regions */
  226. struct list_head busy_extents; /* busy extents in chkpt */
  227. struct xfs_log_vec *lv_chain; /* logvecs being pushed */
  228. struct xfs_log_callback log_cb; /* completion callback hook. */
  229. struct list_head committing; /* ctx committing list */
  230. struct work_struct discard_endio_work;
  231. };
  232. /*
  233. * Committed Item List structure
  234. *
  235. * This structure is used to track log items that have been committed but not
  236. * yet written into the log. It is used only when the delayed logging mount
  237. * option is enabled.
  238. *
  239. * This structure tracks the list of committing checkpoint contexts so
  240. * we can avoid the problem of having to hold out new transactions during a
  241. * flush until we have a the commit record LSN of the checkpoint. We can
  242. * traverse the list of committing contexts in xlog_cil_push_lsn() to find a
  243. * sequence match and extract the commit LSN directly from there. If the
  244. * checkpoint is still in the process of committing, we can block waiting for
  245. * the commit LSN to be determined as well. This should make synchronous
  246. * operations almost as efficient as the old logging methods.
  247. */
  248. struct xfs_cil {
  249. struct xlog *xc_log;
  250. struct list_head xc_cil;
  251. spinlock_t xc_cil_lock;
  252. struct rw_semaphore xc_ctx_lock ____cacheline_aligned_in_smp;
  253. struct xfs_cil_ctx *xc_ctx;
  254. spinlock_t xc_push_lock ____cacheline_aligned_in_smp;
  255. xfs_lsn_t xc_push_seq;
  256. struct list_head xc_committing;
  257. wait_queue_head_t xc_commit_wait;
  258. xfs_lsn_t xc_current_sequence;
  259. struct work_struct xc_push_work;
  260. } ____cacheline_aligned_in_smp;
  261. /*
  262. * The amount of log space we allow the CIL to aggregate is difficult to size.
  263. * Whatever we choose, we have to make sure we can get a reservation for the
  264. * log space effectively, that it is large enough to capture sufficient
  265. * relogging to reduce log buffer IO significantly, but it is not too large for
  266. * the log or induces too much latency when writing out through the iclogs. We
  267. * track both space consumed and the number of vectors in the checkpoint
  268. * context, so we need to decide which to use for limiting.
  269. *
  270. * Every log buffer we write out during a push needs a header reserved, which
  271. * is at least one sector and more for v2 logs. Hence we need a reservation of
  272. * at least 512 bytes per 32k of log space just for the LR headers. That means
  273. * 16KB of reservation per megabyte of delayed logging space we will consume,
  274. * plus various headers. The number of headers will vary based on the num of
  275. * io vectors, so limiting on a specific number of vectors is going to result
  276. * in transactions of varying size. IOWs, it is more consistent to track and
  277. * limit space consumed in the log rather than by the number of objects being
  278. * logged in order to prevent checkpoint ticket overruns.
  279. *
  280. * Further, use of static reservations through the log grant mechanism is
  281. * problematic. It introduces a lot of complexity (e.g. reserve grant vs write
  282. * grant) and a significant deadlock potential because regranting write space
  283. * can block on log pushes. Hence if we have to regrant log space during a log
  284. * push, we can deadlock.
  285. *
  286. * However, we can avoid this by use of a dynamic "reservation stealing"
  287. * technique during transaction commit whereby unused reservation space in the
  288. * transaction ticket is transferred to the CIL ctx commit ticket to cover the
  289. * space needed by the checkpoint transaction. This means that we never need to
  290. * specifically reserve space for the CIL checkpoint transaction, nor do we
  291. * need to regrant space once the checkpoint completes. This also means the
  292. * checkpoint transaction ticket is specific to the checkpoint context, rather
  293. * than the CIL itself.
  294. *
  295. * With dynamic reservations, we can effectively make up arbitrary limits for
  296. * the checkpoint size so long as they don't violate any other size rules.
  297. * Recovery imposes a rule that no transaction exceed half the log, so we are
  298. * limited by that. Furthermore, the log transaction reservation subsystem
  299. * tries to keep 25% of the log free, so we need to keep below that limit or we
  300. * risk running out of free log space to start any new transactions.
  301. *
  302. * In order to keep background CIL push efficient, we will set a lower
  303. * threshold at which background pushing is attempted without blocking current
  304. * transaction commits. A separate, higher bound defines when CIL pushes are
  305. * enforced to ensure we stay within our maximum checkpoint size bounds.
  306. * threshold, yet give us plenty of space for aggregation on large logs.
  307. */
  308. #define XLOG_CIL_SPACE_LIMIT(log) (log->l_logsize >> 3)
  309. /*
  310. * ticket grant locks, queues and accounting have their own cachlines
  311. * as these are quite hot and can be operated on concurrently.
  312. */
  313. struct xlog_grant_head {
  314. spinlock_t lock ____cacheline_aligned_in_smp;
  315. struct list_head waiters;
  316. atomic64_t grant;
  317. };
  318. /*
  319. * The reservation head lsn is not made up of a cycle number and block number.
  320. * Instead, it uses a cycle number and byte number. Logs don't expect to
  321. * overflow 31 bits worth of byte offset, so using a byte number will mean
  322. * that round off problems won't occur when releasing partial reservations.
  323. */
  324. struct xlog {
  325. /* The following fields don't need locking */
  326. struct xfs_mount *l_mp; /* mount point */
  327. struct xfs_ail *l_ailp; /* AIL log is working with */
  328. struct xfs_cil *l_cilp; /* CIL log is working with */
  329. struct xfs_buf *l_xbuf; /* extra buffer for log
  330. * wrapping */
  331. struct xfs_buftarg *l_targ; /* buftarg of log */
  332. struct delayed_work l_work; /* background flush work */
  333. uint l_flags;
  334. uint l_quotaoffs_flag; /* XFS_DQ_*, for QUOTAOFFs */
  335. struct list_head *l_buf_cancel_table;
  336. int l_iclog_hsize; /* size of iclog header */
  337. int l_iclog_heads; /* # of iclog header sectors */
  338. uint l_sectBBsize; /* sector size in BBs (2^n) */
  339. int l_iclog_size; /* size of log in bytes */
  340. int l_iclog_size_log; /* log power size of log */
  341. int l_iclog_bufs; /* number of iclog buffers */
  342. xfs_daddr_t l_logBBstart; /* start block of log */
  343. int l_logsize; /* size of log in bytes */
  344. int l_logBBsize; /* size of log in BB chunks */
  345. /* The following block of fields are changed while holding icloglock */
  346. wait_queue_head_t l_flush_wait ____cacheline_aligned_in_smp;
  347. /* waiting for iclog flush */
  348. int l_covered_state;/* state of "covering disk
  349. * log entries" */
  350. xlog_in_core_t *l_iclog; /* head log queue */
  351. spinlock_t l_icloglock; /* grab to change iclog state */
  352. int l_curr_cycle; /* Cycle number of log writes */
  353. int l_prev_cycle; /* Cycle number before last
  354. * block increment */
  355. int l_curr_block; /* current logical log block */
  356. int l_prev_block; /* previous logical log block */
  357. /*
  358. * l_last_sync_lsn and l_tail_lsn are atomics so they can be set and
  359. * read without needing to hold specific locks. To avoid operations
  360. * contending with other hot objects, place each of them on a separate
  361. * cacheline.
  362. */
  363. /* lsn of last LR on disk */
  364. atomic64_t l_last_sync_lsn ____cacheline_aligned_in_smp;
  365. /* lsn of 1st LR with unflushed * buffers */
  366. atomic64_t l_tail_lsn ____cacheline_aligned_in_smp;
  367. struct xlog_grant_head l_reserve_head;
  368. struct xlog_grant_head l_write_head;
  369. struct xfs_kobj l_kobj;
  370. /* The following field are used for debugging; need to hold icloglock */
  371. #ifdef DEBUG
  372. void *l_iclog_bak[XLOG_MAX_ICLOGS];
  373. /* log record crc error injection factor */
  374. uint32_t l_badcrc_factor;
  375. #endif
  376. /* log recovery lsn tracking (for buffer submission */
  377. xfs_lsn_t l_recovery_lsn;
  378. };
  379. #define XLOG_BUF_CANCEL_BUCKET(log, blkno) \
  380. ((log)->l_buf_cancel_table + ((uint64_t)blkno % XLOG_BC_TABLE_SIZE))
  381. #define XLOG_FORCED_SHUTDOWN(log) ((log)->l_flags & XLOG_IO_ERROR)
  382. /* common routines */
  383. extern int
  384. xlog_recover(
  385. struct xlog *log);
  386. extern int
  387. xlog_recover_finish(
  388. struct xlog *log);
  389. extern int
  390. xlog_recover_cancel(struct xlog *);
  391. extern __le32 xlog_cksum(struct xlog *log, struct xlog_rec_header *rhead,
  392. char *dp, int size);
  393. extern kmem_zone_t *xfs_log_ticket_zone;
  394. struct xlog_ticket *
  395. xlog_ticket_alloc(
  396. struct xlog *log,
  397. int unit_bytes,
  398. int count,
  399. char client,
  400. bool permanent,
  401. xfs_km_flags_t alloc_flags);
  402. static inline void
  403. xlog_write_adv_cnt(void **ptr, int *len, int *off, size_t bytes)
  404. {
  405. *ptr += bytes;
  406. *len -= bytes;
  407. *off += bytes;
  408. }
  409. void xlog_print_tic_res(struct xfs_mount *mp, struct xlog_ticket *ticket);
  410. void xlog_print_trans(struct xfs_trans *);
  411. int
  412. xlog_write(
  413. struct xlog *log,
  414. struct xfs_log_vec *log_vector,
  415. struct xlog_ticket *tic,
  416. xfs_lsn_t *start_lsn,
  417. struct xlog_in_core **commit_iclog,
  418. uint flags);
  419. /*
  420. * When we crack an atomic LSN, we sample it first so that the value will not
  421. * change while we are cracking it into the component values. This means we
  422. * will always get consistent component values to work from. This should always
  423. * be used to sample and crack LSNs that are stored and updated in atomic
  424. * variables.
  425. */
  426. static inline void
  427. xlog_crack_atomic_lsn(atomic64_t *lsn, uint *cycle, uint *block)
  428. {
  429. xfs_lsn_t val = atomic64_read(lsn);
  430. *cycle = CYCLE_LSN(val);
  431. *block = BLOCK_LSN(val);
  432. }
  433. /*
  434. * Calculate and assign a value to an atomic LSN variable from component pieces.
  435. */
  436. static inline void
  437. xlog_assign_atomic_lsn(atomic64_t *lsn, uint cycle, uint block)
  438. {
  439. atomic64_set(lsn, xlog_assign_lsn(cycle, block));
  440. }
  441. /*
  442. * When we crack the grant head, we sample it first so that the value will not
  443. * change while we are cracking it into the component values. This means we
  444. * will always get consistent component values to work from.
  445. */
  446. static inline void
  447. xlog_crack_grant_head_val(int64_t val, int *cycle, int *space)
  448. {
  449. *cycle = val >> 32;
  450. *space = val & 0xffffffff;
  451. }
  452. static inline void
  453. xlog_crack_grant_head(atomic64_t *head, int *cycle, int *space)
  454. {
  455. xlog_crack_grant_head_val(atomic64_read(head), cycle, space);
  456. }
  457. static inline int64_t
  458. xlog_assign_grant_head_val(int cycle, int space)
  459. {
  460. return ((int64_t)cycle << 32) | space;
  461. }
  462. static inline void
  463. xlog_assign_grant_head(atomic64_t *head, int cycle, int space)
  464. {
  465. atomic64_set(head, xlog_assign_grant_head_val(cycle, space));
  466. }
  467. /*
  468. * Committed Item List interfaces
  469. */
  470. int xlog_cil_init(struct xlog *log);
  471. void xlog_cil_init_post_recovery(struct xlog *log);
  472. void xlog_cil_destroy(struct xlog *log);
  473. bool xlog_cil_empty(struct xlog *log);
  474. /*
  475. * CIL force routines
  476. */
  477. xfs_lsn_t
  478. xlog_cil_force_lsn(
  479. struct xlog *log,
  480. xfs_lsn_t sequence);
  481. static inline void
  482. xlog_cil_force(struct xlog *log)
  483. {
  484. xlog_cil_force_lsn(log, log->l_cilp->xc_current_sequence);
  485. }
  486. /*
  487. * Unmount record type is used as a pseudo transaction type for the ticket.
  488. * It's value must be outside the range of XFS_TRANS_* values.
  489. */
  490. #define XLOG_UNMOUNT_REC_TYPE (-1U)
  491. /*
  492. * Wrapper function for waiting on a wait queue serialised against wakeups
  493. * by a spinlock. This matches the semantics of all the wait queues used in the
  494. * log code.
  495. */
  496. static inline void xlog_wait(wait_queue_head_t *wq, spinlock_t *lock)
  497. {
  498. DECLARE_WAITQUEUE(wait, current);
  499. add_wait_queue_exclusive(wq, &wait);
  500. __set_current_state(TASK_UNINTERRUPTIBLE);
  501. spin_unlock(lock);
  502. schedule();
  503. remove_wait_queue(wq, &wait);
  504. }
  505. /*
  506. * The LSN is valid so long as it is behind the current LSN. If it isn't, this
  507. * means that the next log record that includes this metadata could have a
  508. * smaller LSN. In turn, this means that the modification in the log would not
  509. * replay.
  510. */
  511. static inline bool
  512. xlog_valid_lsn(
  513. struct xlog *log,
  514. xfs_lsn_t lsn)
  515. {
  516. int cur_cycle;
  517. int cur_block;
  518. bool valid = true;
  519. /*
  520. * First, sample the current lsn without locking to avoid added
  521. * contention from metadata I/O. The current cycle and block are updated
  522. * (in xlog_state_switch_iclogs()) and read here in a particular order
  523. * to avoid false negatives (e.g., thinking the metadata LSN is valid
  524. * when it is not).
  525. *
  526. * The current block is always rewound before the cycle is bumped in
  527. * xlog_state_switch_iclogs() to ensure the current LSN is never seen in
  528. * a transiently forward state. Instead, we can see the LSN in a
  529. * transiently behind state if we happen to race with a cycle wrap.
  530. */
  531. cur_cycle = READ_ONCE(log->l_curr_cycle);
  532. smp_rmb();
  533. cur_block = READ_ONCE(log->l_curr_block);
  534. if ((CYCLE_LSN(lsn) > cur_cycle) ||
  535. (CYCLE_LSN(lsn) == cur_cycle && BLOCK_LSN(lsn) > cur_block)) {
  536. /*
  537. * If the metadata LSN appears invalid, it's possible the check
  538. * above raced with a wrap to the next log cycle. Grab the lock
  539. * to check for sure.
  540. */
  541. spin_lock(&log->l_icloglock);
  542. cur_cycle = log->l_curr_cycle;
  543. cur_block = log->l_curr_block;
  544. spin_unlock(&log->l_icloglock);
  545. if ((CYCLE_LSN(lsn) > cur_cycle) ||
  546. (CYCLE_LSN(lsn) == cur_cycle && BLOCK_LSN(lsn) > cur_block))
  547. valid = false;
  548. }
  549. return valid;
  550. }
  551. #endif /* __XFS_LOG_PRIV_H__ */