mds_client.h 18 KB

123456789101112131415161718192021222324252627282930313233343536373839404142434445464748495051525354555657585960616263646566676869707172737475767778798081828384858687888990919293949596979899100101102103104105106107108109110111112113114115116117118119120121122123124125126127128129130131132133134135136137138139140141142143144145146147148149150151152153154155156157158159160161162163164165166167168169170171172173174175176177178179180181182183184185186187188189190191192193194195196197198199200201202203204205206207208209210211212213214215216217218219220221222223224225226227228229230231232233234235236237238239240241242243244245246247248249250251252253254255256257258259260261262263264265266267268269270271272273274275276277278279280281282283284285286287288289290291292293294295296297298299300301302303304305306307308309310311312313314315316317318319320321322323324325326327328329330331332333334335336337338339340341342343344345346347348349350351352353354355356357358359360361362363364365366367368369370371372373374375376377378379380381382383384385386387388389390391392393394395396397398399400401402403404405406407408409410411412413414415416417418419420421422423424425426427428429430431432433434435436437438439440441442443444445446447448449450451452453454455456457458459460461462463464465466467468469470471472473474475476477478479480481482483484485486487488489490491492493494495496497498499500501502503504505506507508509510511512513514515516517518519520521522523524525526527528529530531532533534535536537538539540541542543544545546547548549550551552553554555556557558559560561562563564565566567568569570571572573574575576577578579580581582583584585586587588589590591592593594595596597
  1. /* SPDX-License-Identifier: GPL-2.0 */
  2. #ifndef _FS_CEPH_MDS_CLIENT_H
  3. #define _FS_CEPH_MDS_CLIENT_H
  4. #include <linux/completion.h>
  5. #include <linux/kref.h>
  6. #include <linux/list.h>
  7. #include <linux/mutex.h>
  8. #include <linux/rbtree.h>
  9. #include <linux/spinlock.h>
  10. #include <linux/refcount.h>
  11. #include <linux/utsname.h>
  12. #include <linux/ktime.h>
  13. #include <linux/ceph/types.h>
  14. #include <linux/ceph/messenger.h>
  15. #include <linux/ceph/mdsmap.h>
  16. #include <linux/ceph/auth.h>
  17. #include "metric.h"
  18. #include "super.h"
  19. /* The first 8 bits are reserved for old ceph releases */
  20. enum ceph_feature_type {
  21. CEPHFS_FEATURE_MIMIC = 8,
  22. CEPHFS_FEATURE_REPLY_ENCODING,
  23. CEPHFS_FEATURE_RECLAIM_CLIENT,
  24. CEPHFS_FEATURE_LAZY_CAP_WANTED,
  25. CEPHFS_FEATURE_MULTI_RECONNECT,
  26. CEPHFS_FEATURE_DELEG_INO,
  27. CEPHFS_FEATURE_METRIC_COLLECT,
  28. CEPHFS_FEATURE_ALTERNATE_NAME,
  29. CEPHFS_FEATURE_NOTIFY_SESSION_STATE,
  30. CEPHFS_FEATURE_OP_GETVXATTR,
  31. CEPHFS_FEATURE_MAX = CEPHFS_FEATURE_OP_GETVXATTR,
  32. };
  33. #define CEPHFS_FEATURES_CLIENT_SUPPORTED { \
  34. 0, 1, 2, 3, 4, 5, 6, 7, \
  35. CEPHFS_FEATURE_MIMIC, \
  36. CEPHFS_FEATURE_REPLY_ENCODING, \
  37. CEPHFS_FEATURE_LAZY_CAP_WANTED, \
  38. CEPHFS_FEATURE_MULTI_RECONNECT, \
  39. CEPHFS_FEATURE_DELEG_INO, \
  40. CEPHFS_FEATURE_METRIC_COLLECT, \
  41. CEPHFS_FEATURE_NOTIFY_SESSION_STATE, \
  42. CEPHFS_FEATURE_OP_GETVXATTR, \
  43. }
  44. /*
  45. * Some lock dependencies:
  46. *
  47. * session->s_mutex
  48. * mdsc->mutex
  49. *
  50. * mdsc->snap_rwsem
  51. *
  52. * ci->i_ceph_lock
  53. * mdsc->snap_flush_lock
  54. * mdsc->cap_delay_lock
  55. *
  56. */
  57. struct ceph_fs_client;
  58. struct ceph_cap;
  59. /*
  60. * parsed info about a single inode. pointers are into the encoded
  61. * on-wire structures within the mds reply message payload.
  62. */
  63. struct ceph_mds_reply_info_in {
  64. struct ceph_mds_reply_inode *in;
  65. struct ceph_dir_layout dir_layout;
  66. u32 symlink_len;
  67. char *symlink;
  68. u32 xattr_len;
  69. char *xattr_data;
  70. u64 inline_version;
  71. u32 inline_len;
  72. char *inline_data;
  73. u32 pool_ns_len;
  74. char *pool_ns_data;
  75. u64 max_bytes;
  76. u64 max_files;
  77. s32 dir_pin;
  78. struct ceph_timespec btime;
  79. struct ceph_timespec snap_btime;
  80. u64 rsnaps;
  81. u64 change_attr;
  82. };
  83. struct ceph_mds_reply_dir_entry {
  84. char *name;
  85. u32 name_len;
  86. struct ceph_mds_reply_lease *lease;
  87. struct ceph_mds_reply_info_in inode;
  88. loff_t offset;
  89. };
  90. struct ceph_mds_reply_xattr {
  91. char *xattr_value;
  92. size_t xattr_value_len;
  93. };
  94. /*
  95. * parsed info about an mds reply, including information about
  96. * either: 1) the target inode and/or its parent directory and dentry,
  97. * and directory contents (for readdir results), or
  98. * 2) the file range lock info (for fcntl F_GETLK results).
  99. */
  100. struct ceph_mds_reply_info_parsed {
  101. struct ceph_mds_reply_head *head;
  102. /* trace */
  103. struct ceph_mds_reply_info_in diri, targeti;
  104. struct ceph_mds_reply_dirfrag *dirfrag;
  105. char *dname;
  106. u32 dname_len;
  107. struct ceph_mds_reply_lease *dlease;
  108. struct ceph_mds_reply_xattr xattr_info;
  109. /* extra */
  110. union {
  111. /* for fcntl F_GETLK results */
  112. struct ceph_filelock *filelock_reply;
  113. /* for readdir results */
  114. struct {
  115. struct ceph_mds_reply_dirfrag *dir_dir;
  116. size_t dir_buf_size;
  117. int dir_nr;
  118. bool dir_end;
  119. bool dir_complete;
  120. bool hash_order;
  121. bool offset_hash;
  122. struct ceph_mds_reply_dir_entry *dir_entries;
  123. };
  124. /* for create results */
  125. struct {
  126. bool has_create_ino;
  127. u64 ino;
  128. };
  129. };
  130. /* encoded blob describing snapshot contexts for certain
  131. operations (e.g., open) */
  132. void *snapblob;
  133. int snapblob_len;
  134. };
  135. /*
  136. * cap releases are batched and sent to the MDS en masse.
  137. *
  138. * Account for per-message overhead of mds_cap_release header
  139. * and __le32 for osd epoch barrier trailing field.
  140. */
  141. #define CEPH_CAPS_PER_RELEASE ((PAGE_SIZE - sizeof(u32) - \
  142. sizeof(struct ceph_mds_cap_release)) / \
  143. sizeof(struct ceph_mds_cap_item))
  144. /*
  145. * state associated with each MDS<->client session
  146. */
  147. enum {
  148. CEPH_MDS_SESSION_NEW = 1,
  149. CEPH_MDS_SESSION_OPENING = 2,
  150. CEPH_MDS_SESSION_OPEN = 3,
  151. CEPH_MDS_SESSION_HUNG = 4,
  152. CEPH_MDS_SESSION_RESTARTING = 5,
  153. CEPH_MDS_SESSION_RECONNECTING = 6,
  154. CEPH_MDS_SESSION_CLOSING = 7,
  155. CEPH_MDS_SESSION_CLOSED = 8,
  156. CEPH_MDS_SESSION_REJECTED = 9,
  157. };
  158. struct ceph_mds_session {
  159. struct ceph_mds_client *s_mdsc;
  160. int s_mds;
  161. int s_state;
  162. unsigned long s_ttl; /* time until mds kills us */
  163. unsigned long s_features;
  164. u64 s_seq; /* incoming msg seq # */
  165. struct mutex s_mutex; /* serialize session messages */
  166. struct ceph_connection s_con;
  167. struct ceph_auth_handshake s_auth;
  168. atomic_t s_cap_gen; /* inc each time we get mds stale msg */
  169. unsigned long s_cap_ttl; /* when session caps expire. protected by s_mutex */
  170. /* protected by s_cap_lock */
  171. spinlock_t s_cap_lock;
  172. refcount_t s_ref;
  173. struct list_head s_caps; /* all caps issued by this session */
  174. struct ceph_cap *s_cap_iterator;
  175. int s_nr_caps;
  176. int s_num_cap_releases;
  177. int s_cap_reconnect;
  178. int s_readonly;
  179. struct list_head s_cap_releases; /* waiting cap_release messages */
  180. struct work_struct s_cap_release_work;
  181. /* See ceph_inode_info->i_dirty_item. */
  182. struct list_head s_cap_dirty; /* inodes w/ dirty caps */
  183. /* See ceph_inode_info->i_flushing_item. */
  184. struct list_head s_cap_flushing; /* inodes w/ flushing caps */
  185. unsigned long s_renew_requested; /* last time we sent a renew req */
  186. u64 s_renew_seq;
  187. struct list_head s_waiting; /* waiting requests */
  188. struct list_head s_unsafe; /* unsafe requests */
  189. struct xarray s_delegated_inos;
  190. };
  191. /*
  192. * modes of choosing which MDS to send a request to
  193. */
  194. enum {
  195. USE_ANY_MDS,
  196. USE_RANDOM_MDS,
  197. USE_AUTH_MDS, /* prefer authoritative mds for this metadata item */
  198. };
  199. struct ceph_mds_request;
  200. struct ceph_mds_client;
  201. /*
  202. * request completion callback
  203. */
  204. typedef void (*ceph_mds_request_callback_t) (struct ceph_mds_client *mdsc,
  205. struct ceph_mds_request *req);
  206. /*
  207. * wait for request completion callback
  208. */
  209. typedef int (*ceph_mds_request_wait_callback_t) (struct ceph_mds_client *mdsc,
  210. struct ceph_mds_request *req);
  211. /*
  212. * an in-flight mds request
  213. */
  214. struct ceph_mds_request {
  215. u64 r_tid; /* transaction id */
  216. struct rb_node r_node;
  217. struct ceph_mds_client *r_mdsc;
  218. struct kref r_kref;
  219. int r_op; /* mds op code */
  220. /* operation on what? */
  221. struct inode *r_inode; /* arg1 */
  222. struct dentry *r_dentry; /* arg1 */
  223. struct dentry *r_old_dentry; /* arg2: rename from or link from */
  224. struct inode *r_old_dentry_dir; /* arg2: old dentry's parent dir */
  225. char *r_path1, *r_path2;
  226. struct ceph_vino r_ino1, r_ino2;
  227. struct inode *r_parent; /* parent dir inode */
  228. struct inode *r_target_inode; /* resulting inode */
  229. #define CEPH_MDS_R_DIRECT_IS_HASH (1) /* r_direct_hash is valid */
  230. #define CEPH_MDS_R_ABORTED (2) /* call was aborted */
  231. #define CEPH_MDS_R_GOT_UNSAFE (3) /* got an unsafe reply */
  232. #define CEPH_MDS_R_GOT_SAFE (4) /* got a safe reply */
  233. #define CEPH_MDS_R_GOT_RESULT (5) /* got a result */
  234. #define CEPH_MDS_R_DID_PREPOPULATE (6) /* prepopulated readdir */
  235. #define CEPH_MDS_R_PARENT_LOCKED (7) /* is r_parent->i_rwsem wlocked? */
  236. #define CEPH_MDS_R_ASYNC (8) /* async request */
  237. unsigned long r_req_flags;
  238. struct mutex r_fill_mutex;
  239. union ceph_mds_request_args r_args;
  240. int r_fmode; /* file mode, if expecting cap */
  241. int r_request_release_offset;
  242. const struct cred *r_cred;
  243. struct timespec64 r_stamp;
  244. /* for choosing which mds to send this request to */
  245. int r_direct_mode;
  246. u32 r_direct_hash; /* choose dir frag based on this dentry hash */
  247. /* data payload is used for xattr ops */
  248. struct ceph_pagelist *r_pagelist;
  249. /* what caps shall we drop? */
  250. int r_inode_drop, r_inode_unless;
  251. int r_dentry_drop, r_dentry_unless;
  252. int r_old_dentry_drop, r_old_dentry_unless;
  253. struct inode *r_old_inode;
  254. int r_old_inode_drop, r_old_inode_unless;
  255. struct ceph_msg *r_request; /* original request */
  256. struct ceph_msg *r_reply;
  257. struct ceph_mds_reply_info_parsed r_reply_info;
  258. int r_err;
  259. u32 r_readdir_offset;
  260. struct page *r_locked_page;
  261. int r_dir_caps;
  262. int r_num_caps;
  263. unsigned long r_timeout; /* optional. jiffies, 0 is "wait forever" */
  264. unsigned long r_started; /* start time to measure timeout against */
  265. unsigned long r_start_latency; /* start time to measure latency */
  266. unsigned long r_end_latency; /* finish time to measure latency */
  267. unsigned long r_request_started; /* start time for mds request only,
  268. used to measure lease durations */
  269. /* link unsafe requests to parent directory, for fsync */
  270. struct inode *r_unsafe_dir;
  271. struct list_head r_unsafe_dir_item;
  272. /* unsafe requests that modify the target inode */
  273. struct list_head r_unsafe_target_item;
  274. struct ceph_mds_session *r_session;
  275. int r_attempts; /* resend attempts */
  276. int r_num_fwd; /* number of forward attempts */
  277. int r_resend_mds; /* mds to resend to next, if any*/
  278. u32 r_sent_on_mseq; /* cap mseq request was sent at*/
  279. u64 r_deleg_ino;
  280. struct list_head r_wait;
  281. struct completion r_completion;
  282. struct completion r_safe_completion;
  283. ceph_mds_request_callback_t r_callback;
  284. struct list_head r_unsafe_item; /* per-session unsafe list item */
  285. long long r_dir_release_cnt;
  286. long long r_dir_ordered_cnt;
  287. int r_readdir_cache_idx;
  288. int r_feature_needed;
  289. struct ceph_cap_reservation r_caps_reservation;
  290. };
  291. struct ceph_pool_perm {
  292. struct rb_node node;
  293. int perm;
  294. s64 pool;
  295. size_t pool_ns_len;
  296. char pool_ns[];
  297. };
  298. struct ceph_snapid_map {
  299. struct rb_node node;
  300. struct list_head lru;
  301. atomic_t ref;
  302. u64 snap;
  303. dev_t dev;
  304. unsigned long last_used;
  305. };
  306. /*
  307. * node for list of quotarealm inodes that are not visible from the filesystem
  308. * mountpoint, but required to handle, e.g. quotas.
  309. */
  310. struct ceph_quotarealm_inode {
  311. struct rb_node node;
  312. u64 ino;
  313. unsigned long timeout; /* last time a lookup failed for this inode */
  314. struct mutex mutex;
  315. struct inode *inode;
  316. };
  317. struct cap_wait {
  318. struct list_head list;
  319. u64 ino;
  320. pid_t tgid;
  321. int need;
  322. int want;
  323. };
  324. enum {
  325. CEPH_MDSC_STOPPING_BEGIN = 1,
  326. CEPH_MDSC_STOPPING_FLUSHING = 2,
  327. CEPH_MDSC_STOPPING_FLUSHED = 3,
  328. };
  329. /*
  330. * mds client state
  331. */
  332. struct ceph_mds_client {
  333. struct ceph_fs_client *fsc;
  334. struct mutex mutex; /* all nested structures */
  335. struct ceph_mdsmap *mdsmap;
  336. struct completion safe_umount_waiters;
  337. wait_queue_head_t session_close_wq;
  338. struct list_head waiting_for_map;
  339. int mdsmap_err;
  340. struct ceph_mds_session **sessions; /* NULL for mds if no session */
  341. atomic_t num_sessions;
  342. int max_sessions; /* len of sessions array */
  343. spinlock_t stopping_lock; /* protect snap_empty */
  344. int stopping; /* the stage of shutting down */
  345. atomic_t stopping_blockers;
  346. struct completion stopping_waiter;
  347. atomic64_t quotarealms_count; /* # realms with quota */
  348. /*
  349. * We keep a list of inodes we don't see in the mountpoint but that we
  350. * need to track quota realms.
  351. */
  352. struct rb_root quotarealms_inodes;
  353. struct mutex quotarealms_inodes_mutex;
  354. /*
  355. * snap_rwsem will cover cap linkage into snaprealms, and
  356. * realm snap contexts. (later, we can do per-realm snap
  357. * contexts locks..) the empty list contains realms with no
  358. * references (implying they contain no inodes with caps) that
  359. * should be destroyed.
  360. */
  361. u64 last_snap_seq;
  362. struct rw_semaphore snap_rwsem;
  363. struct rb_root snap_realms;
  364. struct list_head snap_empty;
  365. int num_snap_realms;
  366. spinlock_t snap_empty_lock; /* protect snap_empty */
  367. u64 last_tid; /* most recent mds request */
  368. u64 oldest_tid; /* oldest incomplete mds request,
  369. excluding setfilelock requests */
  370. struct rb_root request_tree; /* pending mds requests */
  371. struct delayed_work delayed_work; /* delayed work */
  372. unsigned long last_renew_caps; /* last time we renewed our caps */
  373. struct list_head cap_delay_list; /* caps with delayed release */
  374. spinlock_t cap_delay_lock; /* protects cap_delay_list */
  375. struct list_head snap_flush_list; /* cap_snaps ready to flush */
  376. spinlock_t snap_flush_lock;
  377. u64 last_cap_flush_tid;
  378. struct list_head cap_flush_list;
  379. struct list_head cap_dirty_migrating; /* ...that are migration... */
  380. int num_cap_flushing; /* # caps we are flushing */
  381. spinlock_t cap_dirty_lock; /* protects above items */
  382. wait_queue_head_t cap_flushing_wq;
  383. struct work_struct cap_reclaim_work;
  384. atomic_t cap_reclaim_pending;
  385. /*
  386. * Cap reservations
  387. *
  388. * Maintain a global pool of preallocated struct ceph_caps, referenced
  389. * by struct ceph_caps_reservations. This ensures that we preallocate
  390. * memory needed to successfully process an MDS response. (If an MDS
  391. * sends us cap information and we fail to process it, we will have
  392. * problems due to the client and MDS being out of sync.)
  393. *
  394. * Reservations are 'owned' by a ceph_cap_reservation context.
  395. */
  396. spinlock_t caps_list_lock;
  397. struct list_head caps_list; /* unused (reserved or
  398. unreserved) */
  399. struct list_head cap_wait_list;
  400. int caps_total_count; /* total caps allocated */
  401. int caps_use_count; /* in use */
  402. int caps_use_max; /* max used caps */
  403. int caps_reserve_count; /* unused, reserved */
  404. int caps_avail_count; /* unused, unreserved */
  405. int caps_min_count; /* keep at least this many
  406. (unreserved) */
  407. spinlock_t dentry_list_lock;
  408. struct list_head dentry_leases; /* fifo list */
  409. struct list_head dentry_dir_leases; /* lru list */
  410. struct ceph_client_metric metric;
  411. spinlock_t snapid_map_lock;
  412. struct rb_root snapid_map_tree;
  413. struct list_head snapid_map_lru;
  414. struct rw_semaphore pool_perm_rwsem;
  415. struct rb_root pool_perm_tree;
  416. char nodename[__NEW_UTS_LEN + 1];
  417. };
  418. extern const char *ceph_mds_op_name(int op);
  419. extern bool check_session_state(struct ceph_mds_session *s);
  420. void inc_session_sequence(struct ceph_mds_session *s);
  421. extern struct ceph_mds_session *
  422. __ceph_lookup_mds_session(struct ceph_mds_client *, int mds);
  423. extern const char *ceph_session_state_name(int s);
  424. extern struct ceph_mds_session *
  425. ceph_get_mds_session(struct ceph_mds_session *s);
  426. extern void ceph_put_mds_session(struct ceph_mds_session *s);
  427. extern int ceph_send_msg_mds(struct ceph_mds_client *mdsc,
  428. struct ceph_msg *msg, int mds);
  429. extern int ceph_mdsc_init(struct ceph_fs_client *fsc);
  430. extern void ceph_mdsc_close_sessions(struct ceph_mds_client *mdsc);
  431. extern void ceph_mdsc_force_umount(struct ceph_mds_client *mdsc);
  432. extern void ceph_mdsc_destroy(struct ceph_fs_client *fsc);
  433. extern void ceph_mdsc_sync(struct ceph_mds_client *mdsc);
  434. extern void ceph_invalidate_dir_request(struct ceph_mds_request *req);
  435. extern int ceph_alloc_readdir_reply_buffer(struct ceph_mds_request *req,
  436. struct inode *dir);
  437. extern struct ceph_mds_request *
  438. ceph_mdsc_create_request(struct ceph_mds_client *mdsc, int op, int mode);
  439. extern int ceph_mdsc_submit_request(struct ceph_mds_client *mdsc,
  440. struct inode *dir,
  441. struct ceph_mds_request *req);
  442. int ceph_mdsc_wait_request(struct ceph_mds_client *mdsc,
  443. struct ceph_mds_request *req,
  444. ceph_mds_request_wait_callback_t wait_func);
  445. extern int ceph_mdsc_do_request(struct ceph_mds_client *mdsc,
  446. struct inode *dir,
  447. struct ceph_mds_request *req);
  448. extern void ceph_mdsc_release_dir_caps(struct ceph_mds_request *req);
  449. extern void ceph_mdsc_release_dir_caps_no_check(struct ceph_mds_request *req);
  450. static inline void ceph_mdsc_get_request(struct ceph_mds_request *req)
  451. {
  452. kref_get(&req->r_kref);
  453. }
  454. extern void ceph_mdsc_release_request(struct kref *kref);
  455. static inline void ceph_mdsc_put_request(struct ceph_mds_request *req)
  456. {
  457. kref_put(&req->r_kref, ceph_mdsc_release_request);
  458. }
  459. extern void send_flush_mdlog(struct ceph_mds_session *s);
  460. extern void ceph_mdsc_iterate_sessions(struct ceph_mds_client *mdsc,
  461. void (*cb)(struct ceph_mds_session *),
  462. bool check_state);
  463. extern struct ceph_msg *ceph_create_session_msg(u32 op, u64 seq);
  464. extern void __ceph_queue_cap_release(struct ceph_mds_session *session,
  465. struct ceph_cap *cap);
  466. extern void ceph_flush_cap_releases(struct ceph_mds_client *mdsc,
  467. struct ceph_mds_session *session);
  468. extern void ceph_queue_cap_reclaim_work(struct ceph_mds_client *mdsc);
  469. extern void ceph_reclaim_caps_nr(struct ceph_mds_client *mdsc, int nr);
  470. extern int ceph_iterate_session_caps(struct ceph_mds_session *session,
  471. int (*cb)(struct inode *, int mds, void *),
  472. void *arg);
  473. extern void ceph_mdsc_pre_umount(struct ceph_mds_client *mdsc);
  474. static inline void ceph_mdsc_free_path(char *path, int len)
  475. {
  476. if (!IS_ERR_OR_NULL(path))
  477. __putname(path - (PATH_MAX - 1 - len));
  478. }
  479. extern char *ceph_mdsc_build_path(struct dentry *dentry, int *plen, u64 *base,
  480. int stop_on_nosnap);
  481. extern void __ceph_mdsc_drop_dentry_lease(struct dentry *dentry);
  482. extern void ceph_mdsc_lease_send_msg(struct ceph_mds_session *session,
  483. struct dentry *dentry, char action,
  484. u32 seq);
  485. extern void ceph_mdsc_handle_mdsmap(struct ceph_mds_client *mdsc,
  486. struct ceph_msg *msg);
  487. extern void ceph_mdsc_handle_fsmap(struct ceph_mds_client *mdsc,
  488. struct ceph_msg *msg);
  489. extern struct ceph_mds_session *
  490. ceph_mdsc_open_export_target_session(struct ceph_mds_client *mdsc, int target);
  491. extern void ceph_mdsc_open_export_target_sessions(struct ceph_mds_client *mdsc,
  492. struct ceph_mds_session *session);
  493. extern int ceph_trim_caps(struct ceph_mds_client *mdsc,
  494. struct ceph_mds_session *session,
  495. int max_caps);
  496. static inline int ceph_wait_on_async_create(struct inode *inode)
  497. {
  498. struct ceph_inode_info *ci = ceph_inode(inode);
  499. return wait_on_bit(&ci->i_ceph_flags, CEPH_ASYNC_CREATE_BIT,
  500. TASK_KILLABLE);
  501. }
  502. extern int ceph_wait_on_conflict_unlink(struct dentry *dentry);
  503. extern u64 ceph_get_deleg_ino(struct ceph_mds_session *session);
  504. extern int ceph_restore_deleg_ino(struct ceph_mds_session *session, u64 ino);
  505. #endif