reiserfs.h 117 KB

123456789101112131415161718192021222324252627282930313233343536373839404142434445464748495051525354555657585960616263646566676869707172737475767778798081828384858687888990919293949596979899100101102103104105106107108109110111112113114115116117118119120121122123124125126127128129130131132133134135136137138139140141142143144145146147148149150151152153154155156157158159160161162163164165166167168169170171172173174175176177178179180181182183184185186187188189190191192193194195196197198199200201202203204205206207208209210211212213214215216217218219220221222223224225226227228229230231232233234235236237238239240241242243244245246247248249250251252253254255256257258259260261262263264265266267268269270271272273274275276277278279280281282283284285286287288289290291292293294295296297298299300301302303304305306307308309310311312313314315316317318319320321322323324325326327328329330331332333334335336337338339340341342343344345346347348349350351352353354355356357358359360361362363364365366367368369370371372373374375376377378379380381382383384385386387388389390391392393394395396397398399400401402403404405406407408409410411412413414415416417418419420421422423424425426427428429430431432433434435436437438439440441442443444445446447448449450451452453454455456457458459460461462463464465466467468469470471472473474475476477478479480481482483484485486487488489490491492493494495496497498499500501502503504505506507508509510511512513514515516517518519520521522523524525526527528529530531532533534535536537538539540541542543544545546547548549550551552553554555556557558559560561562563564565566567568569570571572573574575576577578579580581582583584585586587588589590591592593594595596597598599600601602603604605606607608609610611612613614615616617618619620621622623624625626627628629630631632633634635636637638639640641642643644645646647648649650651652653654655656657658659660661662663664665666667668669670671672673674675676677678679680681682683684685686687688689690691692693694695696697698699700701702703704705706707708709710711712713714715716717718719720721722723724725726727728729730731732733734735736737738739740741742743744745746747748749750751752753754755756757758759760761762763764765766767768769770771772773774775776777778779780781782783784785786787788789790791792793794795796797798799800801802803804805806807808809810811812813814815816817818819820821822823824825826827828829830831832833834835836837838839840841842843844845846847848849850851852853854855856857858859860861862863864865866867868869870871872873874875876877878879880881882883884885886887888889890891892893894895896897898899900901902903904905906907908909910911912913914915916917918919920921922923924925926927928929930931932933934935936937938939940941942943944945946947948949950951952953954955956957958959960961962963964965966967968969970971972973974975976977978979980981982983984985986987988989990991992993994995996997998999100010011002100310041005100610071008100910101011101210131014101510161017101810191020102110221023102410251026102710281029103010311032103310341035103610371038103910401041104210431044104510461047104810491050105110521053105410551056105710581059106010611062106310641065106610671068106910701071107210731074107510761077107810791080108110821083108410851086108710881089109010911092109310941095109610971098109911001101110211031104110511061107110811091110111111121113111411151116111711181119112011211122112311241125112611271128112911301131113211331134113511361137113811391140114111421143114411451146114711481149115011511152115311541155115611571158115911601161116211631164116511661167116811691170117111721173117411751176117711781179118011811182118311841185118611871188118911901191119211931194119511961197119811991200120112021203120412051206120712081209121012111212121312141215121612171218121912201221122212231224122512261227122812291230123112321233123412351236123712381239124012411242124312441245124612471248124912501251125212531254125512561257125812591260126112621263126412651266126712681269127012711272127312741275127612771278127912801281128212831284128512861287128812891290129112921293129412951296129712981299130013011302130313041305130613071308130913101311131213131314131513161317131813191320132113221323132413251326132713281329133013311332133313341335133613371338133913401341134213431344134513461347134813491350135113521353135413551356135713581359136013611362136313641365136613671368136913701371137213731374137513761377137813791380138113821383138413851386138713881389139013911392139313941395139613971398139914001401140214031404140514061407140814091410141114121413141414151416141714181419142014211422142314241425142614271428142914301431143214331434143514361437143814391440144114421443144414451446144714481449145014511452145314541455145614571458145914601461146214631464146514661467146814691470147114721473147414751476147714781479148014811482148314841485148614871488148914901491149214931494149514961497149814991500150115021503150415051506150715081509151015111512151315141515151615171518151915201521152215231524152515261527152815291530153115321533153415351536153715381539154015411542154315441545154615471548154915501551155215531554155515561557155815591560156115621563156415651566156715681569157015711572157315741575157615771578157915801581158215831584158515861587158815891590159115921593159415951596159715981599160016011602160316041605160616071608160916101611161216131614161516161617161816191620162116221623162416251626162716281629163016311632163316341635163616371638163916401641164216431644164516461647164816491650165116521653165416551656165716581659166016611662166316641665166616671668166916701671167216731674167516761677167816791680168116821683168416851686168716881689169016911692169316941695169616971698169917001701170217031704170517061707170817091710171117121713171417151716171717181719172017211722172317241725172617271728172917301731173217331734173517361737173817391740174117421743174417451746174717481749175017511752175317541755175617571758175917601761176217631764176517661767176817691770177117721773177417751776177717781779178017811782178317841785178617871788178917901791179217931794179517961797179817991800180118021803180418051806180718081809181018111812181318141815181618171818181918201821182218231824182518261827182818291830183118321833183418351836183718381839184018411842184318441845184618471848184918501851185218531854185518561857185818591860186118621863186418651866186718681869187018711872187318741875187618771878187918801881188218831884188518861887188818891890189118921893189418951896189718981899190019011902190319041905190619071908190919101911191219131914191519161917191819191920192119221923192419251926192719281929193019311932193319341935193619371938193919401941194219431944194519461947194819491950195119521953195419551956195719581959196019611962196319641965196619671968196919701971197219731974197519761977197819791980198119821983198419851986198719881989199019911992199319941995199619971998199920002001200220032004200520062007200820092010201120122013201420152016201720182019202020212022202320242025202620272028202920302031203220332034203520362037203820392040204120422043204420452046204720482049205020512052205320542055205620572058205920602061206220632064206520662067206820692070207120722073207420752076207720782079208020812082208320842085208620872088208920902091209220932094209520962097209820992100210121022103210421052106210721082109211021112112211321142115211621172118211921202121212221232124212521262127212821292130213121322133213421352136213721382139214021412142214321442145214621472148214921502151215221532154215521562157215821592160216121622163216421652166216721682169217021712172217321742175217621772178217921802181218221832184218521862187218821892190219121922193219421952196219721982199220022012202220322042205220622072208220922102211221222132214221522162217221822192220222122222223222422252226222722282229223022312232223322342235223622372238223922402241224222432244224522462247224822492250225122522253225422552256225722582259226022612262226322642265226622672268226922702271227222732274227522762277227822792280228122822283228422852286228722882289229022912292229322942295229622972298229923002301230223032304230523062307230823092310231123122313231423152316231723182319232023212322232323242325232623272328232923302331233223332334233523362337233823392340234123422343234423452346234723482349235023512352235323542355235623572358235923602361236223632364236523662367236823692370237123722373237423752376237723782379238023812382238323842385238623872388238923902391239223932394239523962397239823992400240124022403240424052406240724082409241024112412241324142415241624172418241924202421242224232424242524262427242824292430243124322433243424352436243724382439244024412442244324442445244624472448244924502451245224532454245524562457245824592460246124622463246424652466246724682469247024712472247324742475247624772478247924802481248224832484248524862487248824892490249124922493249424952496249724982499250025012502250325042505250625072508250925102511251225132514251525162517251825192520252125222523252425252526252725282529253025312532253325342535253625372538253925402541254225432544254525462547254825492550255125522553255425552556255725582559256025612562256325642565256625672568256925702571257225732574257525762577257825792580258125822583258425852586258725882589259025912592259325942595259625972598259926002601260226032604260526062607260826092610261126122613261426152616261726182619262026212622262326242625262626272628262926302631263226332634263526362637263826392640264126422643264426452646264726482649265026512652265326542655265626572658265926602661266226632664266526662667266826692670267126722673267426752676267726782679268026812682268326842685268626872688268926902691269226932694269526962697269826992700270127022703270427052706270727082709271027112712271327142715271627172718271927202721272227232724272527262727272827292730273127322733273427352736273727382739274027412742274327442745274627472748274927502751275227532754275527562757275827592760276127622763276427652766276727682769277027712772277327742775277627772778277927802781278227832784278527862787278827892790279127922793279427952796279727982799280028012802280328042805280628072808280928102811281228132814281528162817281828192820282128222823282428252826282728282829283028312832283328342835283628372838283928402841284228432844284528462847284828492850285128522853285428552856285728582859286028612862286328642865286628672868286928702871287228732874287528762877287828792880288128822883288428852886288728882889289028912892289328942895289628972898289929002901290229032904290529062907290829092910291129122913291429152916291729182919292029212922292329242925292629272928292929302931293229332934293529362937293829392940294129422943294429452946294729482949295029512952295329542955295629572958295929602961296229632964296529662967296829692970297129722973297429752976297729782979298029812982298329842985298629872988298929902991299229932994299529962997299829993000300130023003300430053006300730083009301030113012301330143015301630173018301930203021302230233024302530263027302830293030303130323033303430353036303730383039304030413042304330443045304630473048304930503051305230533054305530563057305830593060306130623063306430653066306730683069307030713072307330743075307630773078307930803081308230833084308530863087308830893090309130923093309430953096309730983099310031013102310331043105310631073108310931103111311231133114311531163117311831193120312131223123312431253126312731283129313031313132313331343135313631373138313931403141314231433144314531463147314831493150315131523153315431553156315731583159316031613162316331643165316631673168316931703171317231733174317531763177317831793180318131823183318431853186318731883189319031913192319331943195319631973198319932003201320232033204320532063207320832093210321132123213321432153216321732183219322032213222322332243225322632273228322932303231323232333234323532363237323832393240324132423243324432453246324732483249325032513252325332543255325632573258325932603261326232633264326532663267326832693270327132723273327432753276327732783279328032813282328332843285328632873288328932903291329232933294329532963297329832993300330133023303330433053306330733083309331033113312331333143315331633173318331933203321332233233324332533263327332833293330333133323333333433353336333733383339334033413342334333443345334633473348334933503351335233533354335533563357335833593360336133623363336433653366336733683369337033713372337333743375337633773378337933803381338233833384338533863387338833893390339133923393339433953396339733983399340034013402340334043405340634073408
  1. /*
  2. * Copyright 1996, 1997, 1998 Hans Reiser, see reiserfs/README for
  3. * licensing and copyright details
  4. */
  5. #include <linux/reiserfs_fs.h>
  6. #include <linux/slab.h>
  7. #include <linux/interrupt.h>
  8. #include <linux/sched.h>
  9. #include <linux/bug.h>
  10. #include <linux/workqueue.h>
  11. #include <asm/unaligned.h>
  12. #include <linux/bitops.h>
  13. #include <linux/proc_fs.h>
  14. #include <linux/buffer_head.h>
  15. /* the 32 bit compat definitions with int argument */
  16. #define REISERFS_IOC32_UNPACK _IOW(0xCD, 1, int)
  17. #define REISERFS_IOC32_GETFLAGS FS_IOC32_GETFLAGS
  18. #define REISERFS_IOC32_SETFLAGS FS_IOC32_SETFLAGS
  19. #define REISERFS_IOC32_GETVERSION FS_IOC32_GETVERSION
  20. #define REISERFS_IOC32_SETVERSION FS_IOC32_SETVERSION
  21. struct reiserfs_journal_list;
  22. /* bitmasks for i_flags field in reiserfs-specific part of inode */
  23. typedef enum {
  24. /*
  25. * this says what format of key do all items (but stat data) of
  26. * an object have. If this is set, that format is 3.6 otherwise - 3.5
  27. */
  28. i_item_key_version_mask = 0x0001,
  29. /*
  30. * If this is unset, object has 3.5 stat data, otherwise,
  31. * it has 3.6 stat data with 64bit size, 32bit nlink etc.
  32. */
  33. i_stat_data_version_mask = 0x0002,
  34. /* file might need tail packing on close */
  35. i_pack_on_close_mask = 0x0004,
  36. /* don't pack tail of file */
  37. i_nopack_mask = 0x0008,
  38. /*
  39. * If either of these are set, "safe link" was created for this
  40. * file during truncate or unlink. Safe link is used to avoid
  41. * leakage of disk space on crash with some files open, but unlinked.
  42. */
  43. i_link_saved_unlink_mask = 0x0010,
  44. i_link_saved_truncate_mask = 0x0020,
  45. i_has_xattr_dir = 0x0040,
  46. i_data_log = 0x0080,
  47. } reiserfs_inode_flags;
  48. struct reiserfs_inode_info {
  49. __u32 i_key[4]; /* key is still 4 32 bit integers */
  50. /*
  51. * transient inode flags that are never stored on disk. Bitmasks
  52. * for this field are defined above.
  53. */
  54. __u32 i_flags;
  55. /* offset of first byte stored in direct item. */
  56. __u32 i_first_direct_byte;
  57. /* copy of persistent inode flags read from sd_attrs. */
  58. __u32 i_attrs;
  59. /* first unused block of a sequence of unused blocks */
  60. int i_prealloc_block;
  61. int i_prealloc_count; /* length of that sequence */
  62. /* per-transaction list of inodes which have preallocated blocks */
  63. struct list_head i_prealloc_list;
  64. /*
  65. * new_packing_locality is created; new blocks for the contents
  66. * of this directory should be displaced
  67. */
  68. unsigned new_packing_locality:1;
  69. /*
  70. * we use these for fsync or O_SYNC to decide which transaction
  71. * needs to be committed in order for this inode to be properly
  72. * flushed
  73. */
  74. unsigned int i_trans_id;
  75. struct reiserfs_journal_list *i_jl;
  76. atomic_t openers;
  77. struct mutex tailpack;
  78. #ifdef CONFIG_REISERFS_FS_XATTR
  79. struct rw_semaphore i_xattr_sem;
  80. #endif
  81. struct inode vfs_inode;
  82. };
  83. typedef enum {
  84. reiserfs_attrs_cleared = 0x00000001,
  85. } reiserfs_super_block_flags;
  86. /*
  87. * struct reiserfs_super_block accessors/mutators since this is a disk
  88. * structure, it will always be in little endian format.
  89. */
  90. #define sb_block_count(sbp) (le32_to_cpu((sbp)->s_v1.s_block_count))
  91. #define set_sb_block_count(sbp,v) ((sbp)->s_v1.s_block_count = cpu_to_le32(v))
  92. #define sb_free_blocks(sbp) (le32_to_cpu((sbp)->s_v1.s_free_blocks))
  93. #define set_sb_free_blocks(sbp,v) ((sbp)->s_v1.s_free_blocks = cpu_to_le32(v))
  94. #define sb_root_block(sbp) (le32_to_cpu((sbp)->s_v1.s_root_block))
  95. #define set_sb_root_block(sbp,v) ((sbp)->s_v1.s_root_block = cpu_to_le32(v))
  96. #define sb_jp_journal_1st_block(sbp) \
  97. (le32_to_cpu((sbp)->s_v1.s_journal.jp_journal_1st_block))
  98. #define set_sb_jp_journal_1st_block(sbp,v) \
  99. ((sbp)->s_v1.s_journal.jp_journal_1st_block = cpu_to_le32(v))
  100. #define sb_jp_journal_dev(sbp) \
  101. (le32_to_cpu((sbp)->s_v1.s_journal.jp_journal_dev))
  102. #define set_sb_jp_journal_dev(sbp,v) \
  103. ((sbp)->s_v1.s_journal.jp_journal_dev = cpu_to_le32(v))
  104. #define sb_jp_journal_size(sbp) \
  105. (le32_to_cpu((sbp)->s_v1.s_journal.jp_journal_size))
  106. #define set_sb_jp_journal_size(sbp,v) \
  107. ((sbp)->s_v1.s_journal.jp_journal_size = cpu_to_le32(v))
  108. #define sb_jp_journal_trans_max(sbp) \
  109. (le32_to_cpu((sbp)->s_v1.s_journal.jp_journal_trans_max))
  110. #define set_sb_jp_journal_trans_max(sbp,v) \
  111. ((sbp)->s_v1.s_journal.jp_journal_trans_max = cpu_to_le32(v))
  112. #define sb_jp_journal_magic(sbp) \
  113. (le32_to_cpu((sbp)->s_v1.s_journal.jp_journal_magic))
  114. #define set_sb_jp_journal_magic(sbp,v) \
  115. ((sbp)->s_v1.s_journal.jp_journal_magic = cpu_to_le32(v))
  116. #define sb_jp_journal_max_batch(sbp) \
  117. (le32_to_cpu((sbp)->s_v1.s_journal.jp_journal_max_batch))
  118. #define set_sb_jp_journal_max_batch(sbp,v) \
  119. ((sbp)->s_v1.s_journal.jp_journal_max_batch = cpu_to_le32(v))
  120. #define sb_jp_jourmal_max_commit_age(sbp) \
  121. (le32_to_cpu((sbp)->s_v1.s_journal.jp_journal_max_commit_age))
  122. #define set_sb_jp_journal_max_commit_age(sbp,v) \
  123. ((sbp)->s_v1.s_journal.jp_journal_max_commit_age = cpu_to_le32(v))
  124. #define sb_blocksize(sbp) (le16_to_cpu((sbp)->s_v1.s_blocksize))
  125. #define set_sb_blocksize(sbp,v) ((sbp)->s_v1.s_blocksize = cpu_to_le16(v))
  126. #define sb_oid_maxsize(sbp) (le16_to_cpu((sbp)->s_v1.s_oid_maxsize))
  127. #define set_sb_oid_maxsize(sbp,v) ((sbp)->s_v1.s_oid_maxsize = cpu_to_le16(v))
  128. #define sb_oid_cursize(sbp) (le16_to_cpu((sbp)->s_v1.s_oid_cursize))
  129. #define set_sb_oid_cursize(sbp,v) ((sbp)->s_v1.s_oid_cursize = cpu_to_le16(v))
  130. #define sb_umount_state(sbp) (le16_to_cpu((sbp)->s_v1.s_umount_state))
  131. #define set_sb_umount_state(sbp,v) ((sbp)->s_v1.s_umount_state = cpu_to_le16(v))
  132. #define sb_fs_state(sbp) (le16_to_cpu((sbp)->s_v1.s_fs_state))
  133. #define set_sb_fs_state(sbp,v) ((sbp)->s_v1.s_fs_state = cpu_to_le16(v))
  134. #define sb_hash_function_code(sbp) \
  135. (le32_to_cpu((sbp)->s_v1.s_hash_function_code))
  136. #define set_sb_hash_function_code(sbp,v) \
  137. ((sbp)->s_v1.s_hash_function_code = cpu_to_le32(v))
  138. #define sb_tree_height(sbp) (le16_to_cpu((sbp)->s_v1.s_tree_height))
  139. #define set_sb_tree_height(sbp,v) ((sbp)->s_v1.s_tree_height = cpu_to_le16(v))
  140. #define sb_bmap_nr(sbp) (le16_to_cpu((sbp)->s_v1.s_bmap_nr))
  141. #define set_sb_bmap_nr(sbp,v) ((sbp)->s_v1.s_bmap_nr = cpu_to_le16(v))
  142. #define sb_version(sbp) (le16_to_cpu((sbp)->s_v1.s_version))
  143. #define set_sb_version(sbp,v) ((sbp)->s_v1.s_version = cpu_to_le16(v))
  144. #define sb_mnt_count(sbp) (le16_to_cpu((sbp)->s_mnt_count))
  145. #define set_sb_mnt_count(sbp, v) ((sbp)->s_mnt_count = cpu_to_le16(v))
  146. #define sb_reserved_for_journal(sbp) \
  147. (le16_to_cpu((sbp)->s_v1.s_reserved_for_journal))
  148. #define set_sb_reserved_for_journal(sbp,v) \
  149. ((sbp)->s_v1.s_reserved_for_journal = cpu_to_le16(v))
  150. /* LOGGING -- */
  151. /*
  152. * These all interelate for performance.
  153. *
  154. * If the journal block count is smaller than n transactions, you lose speed.
  155. * I don't know what n is yet, I'm guessing 8-16.
  156. *
  157. * typical transaction size depends on the application, how often fsync is
  158. * called, and how many metadata blocks you dirty in a 30 second period.
  159. * The more small files (<16k) you use, the larger your transactions will
  160. * be.
  161. *
  162. * If your journal fills faster than dirty buffers get flushed to disk, it
  163. * must flush them before allowing the journal to wrap, which slows things
  164. * down. If you need high speed meta data updates, the journal should be
  165. * big enough to prevent wrapping before dirty meta blocks get to disk.
  166. *
  167. * If the batch max is smaller than the transaction max, you'll waste space
  168. * at the end of the journal because journal_end sets the next transaction
  169. * to start at 0 if the next transaction has any chance of wrapping.
  170. *
  171. * The large the batch max age, the better the speed, and the more meta
  172. * data changes you'll lose after a crash.
  173. */
  174. /* don't mess with these for a while */
  175. /* we have a node size define somewhere in reiserfs_fs.h. -Hans */
  176. #define JOURNAL_BLOCK_SIZE 4096 /* BUG gotta get rid of this */
  177. #define JOURNAL_MAX_CNODE 1500 /* max cnodes to allocate. */
  178. #define JOURNAL_HASH_SIZE 8192
  179. /* number of copies of the bitmaps to have floating. Must be >= 2 */
  180. #define JOURNAL_NUM_BITMAPS 5
  181. /*
  182. * One of these for every block in every transaction
  183. * Each one is in two hash tables. First, a hash of the current transaction,
  184. * and after journal_end, a hash of all the in memory transactions.
  185. * next and prev are used by the current transaction (journal_hash).
  186. * hnext and hprev are used by journal_list_hash. If a block is in more
  187. * than one transaction, the journal_list_hash links it in multiple times.
  188. * This allows flush_journal_list to remove just the cnode belonging to a
  189. * given transaction.
  190. */
  191. struct reiserfs_journal_cnode {
  192. struct buffer_head *bh; /* real buffer head */
  193. struct super_block *sb; /* dev of real buffer head */
  194. /* block number of real buffer head, == 0 when buffer on disk */
  195. __u32 blocknr;
  196. unsigned long state;
  197. /* journal list this cnode lives in */
  198. struct reiserfs_journal_list *jlist;
  199. struct reiserfs_journal_cnode *next; /* next in transaction list */
  200. struct reiserfs_journal_cnode *prev; /* prev in transaction list */
  201. struct reiserfs_journal_cnode *hprev; /* prev in hash list */
  202. struct reiserfs_journal_cnode *hnext; /* next in hash list */
  203. };
  204. struct reiserfs_bitmap_node {
  205. int id;
  206. char *data;
  207. struct list_head list;
  208. };
  209. struct reiserfs_list_bitmap {
  210. struct reiserfs_journal_list *journal_list;
  211. struct reiserfs_bitmap_node **bitmaps;
  212. };
  213. /*
  214. * one of these for each transaction. The most important part here is the
  215. * j_realblock. this list of cnodes is used to hash all the blocks in all
  216. * the commits, to mark all the real buffer heads dirty once all the commits
  217. * hit the disk, and to make sure every real block in a transaction is on
  218. * disk before allowing the log area to be overwritten
  219. */
  220. struct reiserfs_journal_list {
  221. unsigned long j_start;
  222. unsigned long j_state;
  223. unsigned long j_len;
  224. atomic_t j_nonzerolen;
  225. atomic_t j_commit_left;
  226. /* all commits older than this on disk */
  227. atomic_t j_older_commits_done;
  228. struct mutex j_commit_mutex;
  229. unsigned int j_trans_id;
  230. time_t j_timestamp;
  231. struct reiserfs_list_bitmap *j_list_bitmap;
  232. struct buffer_head *j_commit_bh; /* commit buffer head */
  233. struct reiserfs_journal_cnode *j_realblock;
  234. struct reiserfs_journal_cnode *j_freedlist; /* list of buffers that were freed during this trans. free each of these on flush */
  235. /* time ordered list of all active transactions */
  236. struct list_head j_list;
  237. /*
  238. * time ordered list of all transactions we haven't tried
  239. * to flush yet
  240. */
  241. struct list_head j_working_list;
  242. /* list of tail conversion targets in need of flush before commit */
  243. struct list_head j_tail_bh_list;
  244. /* list of data=ordered buffers in need of flush before commit */
  245. struct list_head j_bh_list;
  246. int j_refcount;
  247. };
  248. struct reiserfs_journal {
  249. struct buffer_head **j_ap_blocks; /* journal blocks on disk */
  250. /* newest journal block */
  251. struct reiserfs_journal_cnode *j_last;
  252. /* oldest journal block. start here for traverse */
  253. struct reiserfs_journal_cnode *j_first;
  254. struct block_device *j_dev_bd;
  255. fmode_t j_dev_mode;
  256. /* first block on s_dev of reserved area journal */
  257. int j_1st_reserved_block;
  258. unsigned long j_state;
  259. unsigned int j_trans_id;
  260. unsigned long j_mount_id;
  261. /* start of current waiting commit (index into j_ap_blocks) */
  262. unsigned long j_start;
  263. unsigned long j_len; /* length of current waiting commit */
  264. /* number of buffers requested by journal_begin() */
  265. unsigned long j_len_alloc;
  266. atomic_t j_wcount; /* count of writers for current commit */
  267. /* batch count. allows turning X transactions into 1 */
  268. unsigned long j_bcount;
  269. /* first unflushed transactions offset */
  270. unsigned long j_first_unflushed_offset;
  271. /* last fully flushed journal timestamp */
  272. unsigned j_last_flush_trans_id;
  273. struct buffer_head *j_header_bh;
  274. time_t j_trans_start_time; /* time this transaction started */
  275. struct mutex j_mutex;
  276. struct mutex j_flush_mutex;
  277. /* wait for current transaction to finish before starting new one */
  278. wait_queue_head_t j_join_wait;
  279. atomic_t j_jlock; /* lock for j_join_wait */
  280. int j_list_bitmap_index; /* number of next list bitmap to use */
  281. /* no more journal begins allowed. MUST sleep on j_join_wait */
  282. int j_must_wait;
  283. /* next journal_end will flush all journal list */
  284. int j_next_full_flush;
  285. /* next journal_end will flush all async commits */
  286. int j_next_async_flush;
  287. int j_cnode_used; /* number of cnodes on the used list */
  288. int j_cnode_free; /* number of cnodes on the free list */
  289. /* max number of blocks in a transaction. */
  290. unsigned int j_trans_max;
  291. /* max number of blocks to batch into a trans */
  292. unsigned int j_max_batch;
  293. /* in seconds, how old can an async commit be */
  294. unsigned int j_max_commit_age;
  295. /* in seconds, how old can a transaction be */
  296. unsigned int j_max_trans_age;
  297. /* the default for the max commit age */
  298. unsigned int j_default_max_commit_age;
  299. struct reiserfs_journal_cnode *j_cnode_free_list;
  300. /* orig pointer returned from vmalloc */
  301. struct reiserfs_journal_cnode *j_cnode_free_orig;
  302. struct reiserfs_journal_list *j_current_jl;
  303. int j_free_bitmap_nodes;
  304. int j_used_bitmap_nodes;
  305. int j_num_lists; /* total number of active transactions */
  306. int j_num_work_lists; /* number that need attention from kreiserfsd */
  307. /* debugging to make sure things are flushed in order */
  308. unsigned int j_last_flush_id;
  309. /* debugging to make sure things are committed in order */
  310. unsigned int j_last_commit_id;
  311. struct list_head j_bitmap_nodes;
  312. struct list_head j_dirty_buffers;
  313. spinlock_t j_dirty_buffers_lock; /* protects j_dirty_buffers */
  314. /* list of all active transactions */
  315. struct list_head j_journal_list;
  316. /* lists that haven't been touched by writeback attempts */
  317. struct list_head j_working_list;
  318. /* hash table for real buffer heads in current trans */
  319. struct reiserfs_journal_cnode *j_hash_table[JOURNAL_HASH_SIZE];
  320. /* hash table for all the real buffer heads in all the transactions */
  321. struct reiserfs_journal_cnode *j_list_hash_table[JOURNAL_HASH_SIZE];
  322. /* array of bitmaps to record the deleted blocks */
  323. struct reiserfs_list_bitmap j_list_bitmap[JOURNAL_NUM_BITMAPS];
  324. /* list of inodes which have preallocated blocks */
  325. struct list_head j_prealloc_list;
  326. int j_persistent_trans;
  327. unsigned long j_max_trans_size;
  328. unsigned long j_max_batch_size;
  329. int j_errno;
  330. /* when flushing ordered buffers, throttle new ordered writers */
  331. struct delayed_work j_work;
  332. struct super_block *j_work_sb;
  333. atomic_t j_async_throttle;
  334. };
  335. enum journal_state_bits {
  336. J_WRITERS_BLOCKED = 1, /* set when new writers not allowed */
  337. J_WRITERS_QUEUED, /* set when log is full due to too many writers */
  338. J_ABORTED, /* set when log is aborted */
  339. };
  340. /* ick. magic string to find desc blocks in the journal */
  341. #define JOURNAL_DESC_MAGIC "ReIsErLB"
  342. typedef __u32(*hashf_t) (const signed char *, int);
  343. struct reiserfs_bitmap_info {
  344. __u32 free_count;
  345. };
  346. struct proc_dir_entry;
  347. #if defined( CONFIG_PROC_FS ) && defined( CONFIG_REISERFS_PROC_INFO )
  348. typedef unsigned long int stat_cnt_t;
  349. typedef struct reiserfs_proc_info_data {
  350. spinlock_t lock;
  351. int exiting;
  352. int max_hash_collisions;
  353. stat_cnt_t breads;
  354. stat_cnt_t bread_miss;
  355. stat_cnt_t search_by_key;
  356. stat_cnt_t search_by_key_fs_changed;
  357. stat_cnt_t search_by_key_restarted;
  358. stat_cnt_t insert_item_restarted;
  359. stat_cnt_t paste_into_item_restarted;
  360. stat_cnt_t cut_from_item_restarted;
  361. stat_cnt_t delete_solid_item_restarted;
  362. stat_cnt_t delete_item_restarted;
  363. stat_cnt_t leaked_oid;
  364. stat_cnt_t leaves_removable;
  365. /*
  366. * balances per level.
  367. * Use explicit 5 as MAX_HEIGHT is not visible yet.
  368. */
  369. stat_cnt_t balance_at[5]; /* XXX */
  370. /* sbk == search_by_key */
  371. stat_cnt_t sbk_read_at[5]; /* XXX */
  372. stat_cnt_t sbk_fs_changed[5];
  373. stat_cnt_t sbk_restarted[5];
  374. stat_cnt_t items_at[5]; /* XXX */
  375. stat_cnt_t free_at[5]; /* XXX */
  376. stat_cnt_t can_node_be_removed[5]; /* XXX */
  377. long int lnum[5]; /* XXX */
  378. long int rnum[5]; /* XXX */
  379. long int lbytes[5]; /* XXX */
  380. long int rbytes[5]; /* XXX */
  381. stat_cnt_t get_neighbors[5];
  382. stat_cnt_t get_neighbors_restart[5];
  383. stat_cnt_t need_l_neighbor[5];
  384. stat_cnt_t need_r_neighbor[5];
  385. stat_cnt_t free_block;
  386. struct __scan_bitmap_stats {
  387. stat_cnt_t call;
  388. stat_cnt_t wait;
  389. stat_cnt_t bmap;
  390. stat_cnt_t retry;
  391. stat_cnt_t in_journal_hint;
  392. stat_cnt_t in_journal_nohint;
  393. stat_cnt_t stolen;
  394. } scan_bitmap;
  395. struct __journal_stats {
  396. stat_cnt_t in_journal;
  397. stat_cnt_t in_journal_bitmap;
  398. stat_cnt_t in_journal_reusable;
  399. stat_cnt_t lock_journal;
  400. stat_cnt_t lock_journal_wait;
  401. stat_cnt_t journal_being;
  402. stat_cnt_t journal_relock_writers;
  403. stat_cnt_t journal_relock_wcount;
  404. stat_cnt_t mark_dirty;
  405. stat_cnt_t mark_dirty_already;
  406. stat_cnt_t mark_dirty_notjournal;
  407. stat_cnt_t restore_prepared;
  408. stat_cnt_t prepare;
  409. stat_cnt_t prepare_retry;
  410. } journal;
  411. } reiserfs_proc_info_data_t;
  412. #else
  413. typedef struct reiserfs_proc_info_data {
  414. } reiserfs_proc_info_data_t;
  415. #endif
  416. /* Number of quota types we support */
  417. #define REISERFS_MAXQUOTAS 2
  418. /* reiserfs union of in-core super block data */
  419. struct reiserfs_sb_info {
  420. /* Buffer containing the super block */
  421. struct buffer_head *s_sbh;
  422. /* Pointer to the on-disk super block in the buffer */
  423. struct reiserfs_super_block *s_rs;
  424. struct reiserfs_bitmap_info *s_ap_bitmap;
  425. /* pointer to journal information */
  426. struct reiserfs_journal *s_journal;
  427. unsigned short s_mount_state; /* reiserfs state (valid, invalid) */
  428. /* Serialize writers access, replace the old bkl */
  429. struct mutex lock;
  430. /* Owner of the lock (can be recursive) */
  431. struct task_struct *lock_owner;
  432. /* Depth of the lock, start from -1 like the bkl */
  433. int lock_depth;
  434. struct workqueue_struct *commit_wq;
  435. /* Comment? -Hans */
  436. void (*end_io_handler) (struct buffer_head *, int);
  437. /*
  438. * pointer to function which is used to sort names in directory.
  439. * Set on mount
  440. */
  441. hashf_t s_hash_function;
  442. /* reiserfs's mount options are set here */
  443. unsigned long s_mount_opt;
  444. /* This is a structure that describes block allocator options */
  445. struct {
  446. /* Bitfield for enable/disable kind of options */
  447. unsigned long bits;
  448. /*
  449. * size started from which we consider file
  450. * to be a large one (in blocks)
  451. */
  452. unsigned long large_file_size;
  453. int border; /* percentage of disk, border takes */
  454. /*
  455. * Minimal file size (in blocks) starting
  456. * from which we do preallocations
  457. */
  458. int preallocmin;
  459. /*
  460. * Number of blocks we try to prealloc when file
  461. * reaches preallocmin size (in blocks) or prealloc_list
  462. is empty.
  463. */
  464. int preallocsize;
  465. } s_alloc_options;
  466. /* Comment? -Hans */
  467. wait_queue_head_t s_wait;
  468. /* increased by one every time the tree gets re-balanced */
  469. atomic_t s_generation_counter;
  470. /* File system properties. Currently holds on-disk FS format */
  471. unsigned long s_properties;
  472. /* session statistics */
  473. int s_disk_reads;
  474. int s_disk_writes;
  475. int s_fix_nodes;
  476. int s_do_balance;
  477. int s_unneeded_left_neighbor;
  478. int s_good_search_by_key_reada;
  479. int s_bmaps;
  480. int s_bmaps_without_search;
  481. int s_direct2indirect;
  482. int s_indirect2direct;
  483. /*
  484. * set up when it's ok for reiserfs_read_inode2() to read from
  485. * disk inode with nlink==0. Currently this is only used during
  486. * finish_unfinished() processing at mount time
  487. */
  488. int s_is_unlinked_ok;
  489. reiserfs_proc_info_data_t s_proc_info_data;
  490. struct proc_dir_entry *procdir;
  491. /* amount of blocks reserved for further allocations */
  492. int reserved_blocks;
  493. /* this lock on now only used to protect reserved_blocks variable */
  494. spinlock_t bitmap_lock;
  495. struct dentry *priv_root; /* root of /.reiserfs_priv */
  496. struct dentry *xattr_root; /* root of /.reiserfs_priv/xattrs */
  497. int j_errno;
  498. int work_queued; /* non-zero delayed work is queued */
  499. struct delayed_work old_work; /* old transactions flush delayed work */
  500. spinlock_t old_work_lock; /* protects old_work and work_queued */
  501. #ifdef CONFIG_QUOTA
  502. char *s_qf_names[REISERFS_MAXQUOTAS];
  503. int s_jquota_fmt;
  504. #endif
  505. char *s_jdev; /* Stored jdev for mount option showing */
  506. #ifdef CONFIG_REISERFS_CHECK
  507. /*
  508. * Detects whether more than one copy of tb exists per superblock
  509. * as a means of checking whether do_balance is executing
  510. * concurrently against another tree reader/writer on a same
  511. * mount point.
  512. */
  513. struct tree_balance *cur_tb;
  514. #endif
  515. };
  516. /* Definitions of reiserfs on-disk properties: */
  517. #define REISERFS_3_5 0
  518. #define REISERFS_3_6 1
  519. #define REISERFS_OLD_FORMAT 2
  520. /* Mount options */
  521. enum reiserfs_mount_options {
  522. /* large tails will be created in a session */
  523. REISERFS_LARGETAIL,
  524. /*
  525. * small (for files less than block size) tails will
  526. * be created in a session
  527. */
  528. REISERFS_SMALLTAIL,
  529. /* replay journal and return 0. Use by fsck */
  530. REPLAYONLY,
  531. /*
  532. * -o conv: causes conversion of old format super block to the
  533. * new format. If not specified - old partition will be dealt
  534. * with in a manner of 3.5.x
  535. */
  536. REISERFS_CONVERT,
  537. /*
  538. * -o hash={tea, rupasov, r5, detect} is meant for properly mounting
  539. * reiserfs disks from 3.5.19 or earlier. 99% of the time, this
  540. * option is not required. If the normal autodection code can't
  541. * determine which hash to use (because both hashes had the same
  542. * value for a file) use this option to force a specific hash.
  543. * It won't allow you to override the existing hash on the FS, so
  544. * if you have a tea hash disk, and mount with -o hash=rupasov,
  545. * the mount will fail.
  546. */
  547. FORCE_TEA_HASH, /* try to force tea hash on mount */
  548. FORCE_RUPASOV_HASH, /* try to force rupasov hash on mount */
  549. FORCE_R5_HASH, /* try to force rupasov hash on mount */
  550. FORCE_HASH_DETECT, /* try to detect hash function on mount */
  551. REISERFS_DATA_LOG,
  552. REISERFS_DATA_ORDERED,
  553. REISERFS_DATA_WRITEBACK,
  554. /*
  555. * used for testing experimental features, makes benchmarking new
  556. * features with and without more convenient, should never be used by
  557. * users in any code shipped to users (ideally)
  558. */
  559. REISERFS_NO_BORDER,
  560. REISERFS_NO_UNHASHED_RELOCATION,
  561. REISERFS_HASHED_RELOCATION,
  562. REISERFS_ATTRS,
  563. REISERFS_XATTRS_USER,
  564. REISERFS_POSIXACL,
  565. REISERFS_EXPOSE_PRIVROOT,
  566. REISERFS_BARRIER_NONE,
  567. REISERFS_BARRIER_FLUSH,
  568. /* Actions on error */
  569. REISERFS_ERROR_PANIC,
  570. REISERFS_ERROR_RO,
  571. REISERFS_ERROR_CONTINUE,
  572. REISERFS_USRQUOTA, /* User quota option specified */
  573. REISERFS_GRPQUOTA, /* Group quota option specified */
  574. REISERFS_TEST1,
  575. REISERFS_TEST2,
  576. REISERFS_TEST3,
  577. REISERFS_TEST4,
  578. REISERFS_UNSUPPORTED_OPT,
  579. };
  580. #define reiserfs_r5_hash(s) (REISERFS_SB(s)->s_mount_opt & (1 << FORCE_R5_HASH))
  581. #define reiserfs_rupasov_hash(s) (REISERFS_SB(s)->s_mount_opt & (1 << FORCE_RUPASOV_HASH))
  582. #define reiserfs_tea_hash(s) (REISERFS_SB(s)->s_mount_opt & (1 << FORCE_TEA_HASH))
  583. #define reiserfs_hash_detect(s) (REISERFS_SB(s)->s_mount_opt & (1 << FORCE_HASH_DETECT))
  584. #define reiserfs_no_border(s) (REISERFS_SB(s)->s_mount_opt & (1 << REISERFS_NO_BORDER))
  585. #define reiserfs_no_unhashed_relocation(s) (REISERFS_SB(s)->s_mount_opt & (1 << REISERFS_NO_UNHASHED_RELOCATION))
  586. #define reiserfs_hashed_relocation(s) (REISERFS_SB(s)->s_mount_opt & (1 << REISERFS_HASHED_RELOCATION))
  587. #define reiserfs_test4(s) (REISERFS_SB(s)->s_mount_opt & (1 << REISERFS_TEST4))
  588. #define have_large_tails(s) (REISERFS_SB(s)->s_mount_opt & (1 << REISERFS_LARGETAIL))
  589. #define have_small_tails(s) (REISERFS_SB(s)->s_mount_opt & (1 << REISERFS_SMALLTAIL))
  590. #define replay_only(s) (REISERFS_SB(s)->s_mount_opt & (1 << REPLAYONLY))
  591. #define reiserfs_attrs(s) (REISERFS_SB(s)->s_mount_opt & (1 << REISERFS_ATTRS))
  592. #define old_format_only(s) (REISERFS_SB(s)->s_properties & (1 << REISERFS_3_5))
  593. #define convert_reiserfs(s) (REISERFS_SB(s)->s_mount_opt & (1 << REISERFS_CONVERT))
  594. #define reiserfs_data_log(s) (REISERFS_SB(s)->s_mount_opt & (1 << REISERFS_DATA_LOG))
  595. #define reiserfs_data_ordered(s) (REISERFS_SB(s)->s_mount_opt & (1 << REISERFS_DATA_ORDERED))
  596. #define reiserfs_data_writeback(s) (REISERFS_SB(s)->s_mount_opt & (1 << REISERFS_DATA_WRITEBACK))
  597. #define reiserfs_xattrs_user(s) (REISERFS_SB(s)->s_mount_opt & (1 << REISERFS_XATTRS_USER))
  598. #define reiserfs_posixacl(s) (REISERFS_SB(s)->s_mount_opt & (1 << REISERFS_POSIXACL))
  599. #define reiserfs_expose_privroot(s) (REISERFS_SB(s)->s_mount_opt & (1 << REISERFS_EXPOSE_PRIVROOT))
  600. #define reiserfs_xattrs_optional(s) (reiserfs_xattrs_user(s) || reiserfs_posixacl(s))
  601. #define reiserfs_barrier_none(s) (REISERFS_SB(s)->s_mount_opt & (1 << REISERFS_BARRIER_NONE))
  602. #define reiserfs_barrier_flush(s) (REISERFS_SB(s)->s_mount_opt & (1 << REISERFS_BARRIER_FLUSH))
  603. #define reiserfs_error_panic(s) (REISERFS_SB(s)->s_mount_opt & (1 << REISERFS_ERROR_PANIC))
  604. #define reiserfs_error_ro(s) (REISERFS_SB(s)->s_mount_opt & (1 << REISERFS_ERROR_RO))
  605. void reiserfs_file_buffer(struct buffer_head *bh, int list);
  606. extern struct file_system_type reiserfs_fs_type;
  607. int reiserfs_resize(struct super_block *, unsigned long);
  608. #define CARRY_ON 0
  609. #define SCHEDULE_OCCURRED 1
  610. #define SB_BUFFER_WITH_SB(s) (REISERFS_SB(s)->s_sbh)
  611. #define SB_JOURNAL(s) (REISERFS_SB(s)->s_journal)
  612. #define SB_JOURNAL_1st_RESERVED_BLOCK(s) (SB_JOURNAL(s)->j_1st_reserved_block)
  613. #define SB_JOURNAL_LEN_FREE(s) (SB_JOURNAL(s)->j_journal_len_free)
  614. #define SB_AP_BITMAP(s) (REISERFS_SB(s)->s_ap_bitmap)
  615. #define SB_DISK_JOURNAL_HEAD(s) (SB_JOURNAL(s)->j_header_bh->)
  616. #define reiserfs_is_journal_aborted(journal) (unlikely (__reiserfs_is_journal_aborted (journal)))
  617. static inline int __reiserfs_is_journal_aborted(struct reiserfs_journal
  618. *journal)
  619. {
  620. return test_bit(J_ABORTED, &journal->j_state);
  621. }
  622. /*
  623. * Locking primitives. The write lock is a per superblock
  624. * special mutex that has properties close to the Big Kernel Lock
  625. * which was used in the previous locking scheme.
  626. */
  627. void reiserfs_write_lock(struct super_block *s);
  628. void reiserfs_write_unlock(struct super_block *s);
  629. int __must_check reiserfs_write_unlock_nested(struct super_block *s);
  630. void reiserfs_write_lock_nested(struct super_block *s, int depth);
  631. #ifdef CONFIG_REISERFS_CHECK
  632. void reiserfs_lock_check_recursive(struct super_block *s);
  633. #else
  634. static inline void reiserfs_lock_check_recursive(struct super_block *s) { }
  635. #endif
  636. /*
  637. * Several mutexes depend on the write lock.
  638. * However sometimes we want to relax the write lock while we hold
  639. * these mutexes, according to the release/reacquire on schedule()
  640. * properties of the Bkl that were used.
  641. * Reiserfs performances and locking were based on this scheme.
  642. * Now that the write lock is a mutex and not the bkl anymore, doing so
  643. * may result in a deadlock:
  644. *
  645. * A acquire write_lock
  646. * A acquire j_commit_mutex
  647. * A release write_lock and wait for something
  648. * B acquire write_lock
  649. * B can't acquire j_commit_mutex and sleep
  650. * A can't acquire write lock anymore
  651. * deadlock
  652. *
  653. * What we do here is avoiding such deadlock by playing the same game
  654. * than the Bkl: if we can't acquire a mutex that depends on the write lock,
  655. * we release the write lock, wait a bit and then retry.
  656. *
  657. * The mutexes concerned by this hack are:
  658. * - The commit mutex of a journal list
  659. * - The flush mutex
  660. * - The journal lock
  661. * - The inode mutex
  662. */
  663. static inline void reiserfs_mutex_lock_safe(struct mutex *m,
  664. struct super_block *s)
  665. {
  666. int depth;
  667. depth = reiserfs_write_unlock_nested(s);
  668. mutex_lock(m);
  669. reiserfs_write_lock_nested(s, depth);
  670. }
  671. static inline void
  672. reiserfs_mutex_lock_nested_safe(struct mutex *m, unsigned int subclass,
  673. struct super_block *s)
  674. {
  675. int depth;
  676. depth = reiserfs_write_unlock_nested(s);
  677. mutex_lock_nested(m, subclass);
  678. reiserfs_write_lock_nested(s, depth);
  679. }
  680. static inline void
  681. reiserfs_down_read_safe(struct rw_semaphore *sem, struct super_block *s)
  682. {
  683. int depth;
  684. depth = reiserfs_write_unlock_nested(s);
  685. down_read(sem);
  686. reiserfs_write_lock_nested(s, depth);
  687. }
  688. /*
  689. * When we schedule, we usually want to also release the write lock,
  690. * according to the previous bkl based locking scheme of reiserfs.
  691. */
  692. static inline void reiserfs_cond_resched(struct super_block *s)
  693. {
  694. if (need_resched()) {
  695. int depth;
  696. depth = reiserfs_write_unlock_nested(s);
  697. schedule();
  698. reiserfs_write_lock_nested(s, depth);
  699. }
  700. }
  701. struct fid;
  702. /*
  703. * in reading the #defines, it may help to understand that they employ
  704. * the following abbreviations:
  705. *
  706. * B = Buffer
  707. * I = Item header
  708. * H = Height within the tree (should be changed to LEV)
  709. * N = Number of the item in the node
  710. * STAT = stat data
  711. * DEH = Directory Entry Header
  712. * EC = Entry Count
  713. * E = Entry number
  714. * UL = Unsigned Long
  715. * BLKH = BLocK Header
  716. * UNFM = UNForMatted node
  717. * DC = Disk Child
  718. * P = Path
  719. *
  720. * These #defines are named by concatenating these abbreviations,
  721. * where first comes the arguments, and last comes the return value,
  722. * of the macro.
  723. */
  724. #define USE_INODE_GENERATION_COUNTER
  725. #define REISERFS_PREALLOCATE
  726. #define DISPLACE_NEW_PACKING_LOCALITIES
  727. #define PREALLOCATION_SIZE 9
  728. /* n must be power of 2 */
  729. #define _ROUND_UP(x,n) (((x)+(n)-1u) & ~((n)-1u))
  730. /*
  731. * to be ok for alpha and others we have to align structures to 8 byte
  732. * boundary.
  733. * FIXME: do not change 4 by anything else: there is code which relies on that
  734. */
  735. #define ROUND_UP(x) _ROUND_UP(x,8LL)
  736. /*
  737. * debug levels. Right now, CONFIG_REISERFS_CHECK means print all debug
  738. * messages.
  739. */
  740. #define REISERFS_DEBUG_CODE 5 /* extra messages to help find/debug errors */
  741. void __reiserfs_warning(struct super_block *s, const char *id,
  742. const char *func, const char *fmt, ...);
  743. #define reiserfs_warning(s, id, fmt, args...) \
  744. __reiserfs_warning(s, id, __func__, fmt, ##args)
  745. /* assertions handling */
  746. /* always check a condition and panic if it's false. */
  747. #define __RASSERT(cond, scond, format, args...) \
  748. do { \
  749. if (!(cond)) \
  750. reiserfs_panic(NULL, "assertion failure", "(" #cond ") at " \
  751. __FILE__ ":%i:%s: " format "\n", \
  752. in_interrupt() ? -1 : task_pid_nr(current), \
  753. __LINE__, __func__ , ##args); \
  754. } while (0)
  755. #define RASSERT(cond, format, args...) __RASSERT(cond, #cond, format, ##args)
  756. #if defined( CONFIG_REISERFS_CHECK )
  757. #define RFALSE(cond, format, args...) __RASSERT(!(cond), "!(" #cond ")", format, ##args)
  758. #else
  759. #define RFALSE( cond, format, args... ) do {;} while( 0 )
  760. #endif
  761. #define CONSTF __attribute_const__
  762. /*
  763. * Disk Data Structures
  764. */
  765. /***************************************************************************
  766. * SUPER BLOCK *
  767. ***************************************************************************/
  768. /*
  769. * Structure of super block on disk, a version of which in RAM is often
  770. * accessed as REISERFS_SB(s)->s_rs. The version in RAM is part of a larger
  771. * structure containing fields never written to disk.
  772. */
  773. #define UNSET_HASH 0 /* Detect hash on disk */
  774. #define TEA_HASH 1
  775. #define YURA_HASH 2
  776. #define R5_HASH 3
  777. #define DEFAULT_HASH R5_HASH
  778. struct journal_params {
  779. /* where does journal start from on its * device */
  780. __le32 jp_journal_1st_block;
  781. /* journal device st_rdev */
  782. __le32 jp_journal_dev;
  783. /* size of the journal */
  784. __le32 jp_journal_size;
  785. /* max number of blocks in a transaction. */
  786. __le32 jp_journal_trans_max;
  787. /*
  788. * random value made on fs creation
  789. * (this was sb_journal_block_count)
  790. */
  791. __le32 jp_journal_magic;
  792. /* max number of blocks to batch into a trans */
  793. __le32 jp_journal_max_batch;
  794. /* in seconds, how old can an async commit be */
  795. __le32 jp_journal_max_commit_age;
  796. /* in seconds, how old can a transaction be */
  797. __le32 jp_journal_max_trans_age;
  798. };
  799. /* this is the super from 3.5.X, where X >= 10 */
  800. struct reiserfs_super_block_v1 {
  801. __le32 s_block_count; /* blocks count */
  802. __le32 s_free_blocks; /* free blocks count */
  803. __le32 s_root_block; /* root block number */
  804. struct journal_params s_journal;
  805. __le16 s_blocksize; /* block size */
  806. /* max size of object id array, see get_objectid() commentary */
  807. __le16 s_oid_maxsize;
  808. __le16 s_oid_cursize; /* current size of object id array */
  809. /* this is set to 1 when filesystem was umounted, to 2 - when not */
  810. __le16 s_umount_state;
  811. /*
  812. * reiserfs magic string indicates that file system is reiserfs:
  813. * "ReIsErFs" or "ReIsEr2Fs" or "ReIsEr3Fs"
  814. */
  815. char s_magic[10];
  816. /*
  817. * it is set to used by fsck to mark which
  818. * phase of rebuilding is done
  819. */
  820. __le16 s_fs_state;
  821. /*
  822. * indicate, what hash function is being use
  823. * to sort names in a directory
  824. */
  825. __le32 s_hash_function_code;
  826. __le16 s_tree_height; /* height of disk tree */
  827. /*
  828. * amount of bitmap blocks needed to address
  829. * each block of file system
  830. */
  831. __le16 s_bmap_nr;
  832. /*
  833. * this field is only reliable on filesystem with non-standard journal
  834. */
  835. __le16 s_version;
  836. /*
  837. * size in blocks of journal area on main device, we need to
  838. * keep after making fs with non-standard journal
  839. */
  840. __le16 s_reserved_for_journal;
  841. } __attribute__ ((__packed__));
  842. #define SB_SIZE_V1 (sizeof(struct reiserfs_super_block_v1))
  843. /* this is the on disk super block */
  844. struct reiserfs_super_block {
  845. struct reiserfs_super_block_v1 s_v1;
  846. __le32 s_inode_generation;
  847. /* Right now used only by inode-attributes, if enabled */
  848. __le32 s_flags;
  849. unsigned char s_uuid[16]; /* filesystem unique identifier */
  850. unsigned char s_label[16]; /* filesystem volume label */
  851. __le16 s_mnt_count; /* Count of mounts since last fsck */
  852. __le16 s_max_mnt_count; /* Maximum mounts before check */
  853. __le32 s_lastcheck; /* Timestamp of last fsck */
  854. __le32 s_check_interval; /* Interval between checks */
  855. /*
  856. * zero filled by mkreiserfs and reiserfs_convert_objectid_map_v1()
  857. * so any additions must be updated there as well. */
  858. char s_unused[76];
  859. } __attribute__ ((__packed__));
  860. #define SB_SIZE (sizeof(struct reiserfs_super_block))
  861. #define REISERFS_VERSION_1 0
  862. #define REISERFS_VERSION_2 2
  863. /* on-disk super block fields converted to cpu form */
  864. #define SB_DISK_SUPER_BLOCK(s) (REISERFS_SB(s)->s_rs)
  865. #define SB_V1_DISK_SUPER_BLOCK(s) (&(SB_DISK_SUPER_BLOCK(s)->s_v1))
  866. #define SB_BLOCKSIZE(s) \
  867. le32_to_cpu ((SB_V1_DISK_SUPER_BLOCK(s)->s_blocksize))
  868. #define SB_BLOCK_COUNT(s) \
  869. le32_to_cpu ((SB_V1_DISK_SUPER_BLOCK(s)->s_block_count))
  870. #define SB_FREE_BLOCKS(s) \
  871. le32_to_cpu ((SB_V1_DISK_SUPER_BLOCK(s)->s_free_blocks))
  872. #define SB_REISERFS_MAGIC(s) \
  873. (SB_V1_DISK_SUPER_BLOCK(s)->s_magic)
  874. #define SB_ROOT_BLOCK(s) \
  875. le32_to_cpu ((SB_V1_DISK_SUPER_BLOCK(s)->s_root_block))
  876. #define SB_TREE_HEIGHT(s) \
  877. le16_to_cpu ((SB_V1_DISK_SUPER_BLOCK(s)->s_tree_height))
  878. #define SB_REISERFS_STATE(s) \
  879. le16_to_cpu ((SB_V1_DISK_SUPER_BLOCK(s)->s_umount_state))
  880. #define SB_VERSION(s) le16_to_cpu ((SB_V1_DISK_SUPER_BLOCK(s)->s_version))
  881. #define SB_BMAP_NR(s) le16_to_cpu ((SB_V1_DISK_SUPER_BLOCK(s)->s_bmap_nr))
  882. #define PUT_SB_BLOCK_COUNT(s, val) \
  883. do { SB_V1_DISK_SUPER_BLOCK(s)->s_block_count = cpu_to_le32(val); } while (0)
  884. #define PUT_SB_FREE_BLOCKS(s, val) \
  885. do { SB_V1_DISK_SUPER_BLOCK(s)->s_free_blocks = cpu_to_le32(val); } while (0)
  886. #define PUT_SB_ROOT_BLOCK(s, val) \
  887. do { SB_V1_DISK_SUPER_BLOCK(s)->s_root_block = cpu_to_le32(val); } while (0)
  888. #define PUT_SB_TREE_HEIGHT(s, val) \
  889. do { SB_V1_DISK_SUPER_BLOCK(s)->s_tree_height = cpu_to_le16(val); } while (0)
  890. #define PUT_SB_REISERFS_STATE(s, val) \
  891. do { SB_V1_DISK_SUPER_BLOCK(s)->s_umount_state = cpu_to_le16(val); } while (0)
  892. #define PUT_SB_VERSION(s, val) \
  893. do { SB_V1_DISK_SUPER_BLOCK(s)->s_version = cpu_to_le16(val); } while (0)
  894. #define PUT_SB_BMAP_NR(s, val) \
  895. do { SB_V1_DISK_SUPER_BLOCK(s)->s_bmap_nr = cpu_to_le16 (val); } while (0)
  896. #define SB_ONDISK_JP(s) (&SB_V1_DISK_SUPER_BLOCK(s)->s_journal)
  897. #define SB_ONDISK_JOURNAL_SIZE(s) \
  898. le32_to_cpu ((SB_ONDISK_JP(s)->jp_journal_size))
  899. #define SB_ONDISK_JOURNAL_1st_BLOCK(s) \
  900. le32_to_cpu ((SB_ONDISK_JP(s)->jp_journal_1st_block))
  901. #define SB_ONDISK_JOURNAL_DEVICE(s) \
  902. le32_to_cpu ((SB_ONDISK_JP(s)->jp_journal_dev))
  903. #define SB_ONDISK_RESERVED_FOR_JOURNAL(s) \
  904. le16_to_cpu ((SB_V1_DISK_SUPER_BLOCK(s)->s_reserved_for_journal))
  905. #define is_block_in_log_or_reserved_area(s, block) \
  906. block >= SB_JOURNAL_1st_RESERVED_BLOCK(s) \
  907. && block < SB_JOURNAL_1st_RESERVED_BLOCK(s) + \
  908. ((!is_reiserfs_jr(SB_DISK_SUPER_BLOCK(s)) ? \
  909. SB_ONDISK_JOURNAL_SIZE(s) + 1 : SB_ONDISK_RESERVED_FOR_JOURNAL(s)))
  910. int is_reiserfs_3_5(struct reiserfs_super_block *rs);
  911. int is_reiserfs_3_6(struct reiserfs_super_block *rs);
  912. int is_reiserfs_jr(struct reiserfs_super_block *rs);
  913. /*
  914. * ReiserFS leaves the first 64k unused, so that partition labels have
  915. * enough space. If someone wants to write a fancy bootloader that
  916. * needs more than 64k, let us know, and this will be increased in size.
  917. * This number must be larger than than the largest block size on any
  918. * platform, or code will break. -Hans
  919. */
  920. #define REISERFS_DISK_OFFSET_IN_BYTES (64 * 1024)
  921. #define REISERFS_FIRST_BLOCK unused_define
  922. #define REISERFS_JOURNAL_OFFSET_IN_BYTES REISERFS_DISK_OFFSET_IN_BYTES
  923. /* the spot for the super in versions 3.5 - 3.5.10 (inclusive) */
  924. #define REISERFS_OLD_DISK_OFFSET_IN_BYTES (8 * 1024)
  925. /* reiserfs internal error code (used by search_by_key and fix_nodes)) */
  926. #define CARRY_ON 0
  927. #define REPEAT_SEARCH -1
  928. #define IO_ERROR -2
  929. #define NO_DISK_SPACE -3
  930. #define NO_BALANCING_NEEDED (-4)
  931. #define NO_MORE_UNUSED_CONTIGUOUS_BLOCKS (-5)
  932. #define QUOTA_EXCEEDED -6
  933. typedef __u32 b_blocknr_t;
  934. typedef __le32 unp_t;
  935. struct unfm_nodeinfo {
  936. unp_t unfm_nodenum;
  937. unsigned short unfm_freespace;
  938. };
  939. /* there are two formats of keys: 3.5 and 3.6 */
  940. #define KEY_FORMAT_3_5 0
  941. #define KEY_FORMAT_3_6 1
  942. /* there are two stat datas */
  943. #define STAT_DATA_V1 0
  944. #define STAT_DATA_V2 1
  945. static inline struct reiserfs_inode_info *REISERFS_I(const struct inode *inode)
  946. {
  947. return container_of(inode, struct reiserfs_inode_info, vfs_inode);
  948. }
  949. static inline struct reiserfs_sb_info *REISERFS_SB(const struct super_block *sb)
  950. {
  951. return sb->s_fs_info;
  952. }
  953. /*
  954. * Don't trust REISERFS_SB(sb)->s_bmap_nr, it's a u16
  955. * which overflows on large file systems.
  956. */
  957. static inline __u32 reiserfs_bmap_count(struct super_block *sb)
  958. {
  959. return (SB_BLOCK_COUNT(sb) - 1) / (sb->s_blocksize * 8) + 1;
  960. }
  961. static inline int bmap_would_wrap(unsigned bmap_nr)
  962. {
  963. return bmap_nr > ((1LL << 16) - 1);
  964. }
  965. /*
  966. * this says about version of key of all items (but stat data) the
  967. * object consists of
  968. */
  969. #define get_inode_item_key_version( inode ) \
  970. ((REISERFS_I(inode)->i_flags & i_item_key_version_mask) ? KEY_FORMAT_3_6 : KEY_FORMAT_3_5)
  971. #define set_inode_item_key_version( inode, version ) \
  972. ({ if((version)==KEY_FORMAT_3_6) \
  973. REISERFS_I(inode)->i_flags |= i_item_key_version_mask; \
  974. else \
  975. REISERFS_I(inode)->i_flags &= ~i_item_key_version_mask; })
  976. #define get_inode_sd_version(inode) \
  977. ((REISERFS_I(inode)->i_flags & i_stat_data_version_mask) ? STAT_DATA_V2 : STAT_DATA_V1)
  978. #define set_inode_sd_version(inode, version) \
  979. ({ if((version)==STAT_DATA_V2) \
  980. REISERFS_I(inode)->i_flags |= i_stat_data_version_mask; \
  981. else \
  982. REISERFS_I(inode)->i_flags &= ~i_stat_data_version_mask; })
  983. /*
  984. * This is an aggressive tail suppression policy, I am hoping it
  985. * improves our benchmarks. The principle behind it is that percentage
  986. * space saving is what matters, not absolute space saving. This is
  987. * non-intuitive, but it helps to understand it if you consider that the
  988. * cost to access 4 blocks is not much more than the cost to access 1
  989. * block, if you have to do a seek and rotate. A tail risks a
  990. * non-linear disk access that is significant as a percentage of total
  991. * time cost for a 4 block file and saves an amount of space that is
  992. * less significant as a percentage of space, or so goes the hypothesis.
  993. * -Hans
  994. */
  995. #define STORE_TAIL_IN_UNFM_S1(n_file_size,n_tail_size,n_block_size) \
  996. (\
  997. (!(n_tail_size)) || \
  998. (((n_tail_size) > MAX_DIRECT_ITEM_LEN(n_block_size)) || \
  999. ( (n_file_size) >= (n_block_size) * 4 ) || \
  1000. ( ( (n_file_size) >= (n_block_size) * 3 ) && \
  1001. ( (n_tail_size) >= (MAX_DIRECT_ITEM_LEN(n_block_size))/4) ) || \
  1002. ( ( (n_file_size) >= (n_block_size) * 2 ) && \
  1003. ( (n_tail_size) >= (MAX_DIRECT_ITEM_LEN(n_block_size))/2) ) || \
  1004. ( ( (n_file_size) >= (n_block_size) ) && \
  1005. ( (n_tail_size) >= (MAX_DIRECT_ITEM_LEN(n_block_size) * 3)/4) ) ) \
  1006. )
  1007. /*
  1008. * Another strategy for tails, this one means only create a tail if all the
  1009. * file would fit into one DIRECT item.
  1010. * Primary intention for this one is to increase performance by decreasing
  1011. * seeking.
  1012. */
  1013. #define STORE_TAIL_IN_UNFM_S2(n_file_size,n_tail_size,n_block_size) \
  1014. (\
  1015. (!(n_tail_size)) || \
  1016. (((n_file_size) > MAX_DIRECT_ITEM_LEN(n_block_size)) ) \
  1017. )
  1018. /*
  1019. * values for s_umount_state field
  1020. */
  1021. #define REISERFS_VALID_FS 1
  1022. #define REISERFS_ERROR_FS 2
  1023. /*
  1024. * there are 5 item types currently
  1025. */
  1026. #define TYPE_STAT_DATA 0
  1027. #define TYPE_INDIRECT 1
  1028. #define TYPE_DIRECT 2
  1029. #define TYPE_DIRENTRY 3
  1030. #define TYPE_MAXTYPE 3
  1031. #define TYPE_ANY 15 /* FIXME: comment is required */
  1032. /***************************************************************************
  1033. * KEY & ITEM HEAD *
  1034. ***************************************************************************/
  1035. /* * directories use this key as well as old files */
  1036. struct offset_v1 {
  1037. __le32 k_offset;
  1038. __le32 k_uniqueness;
  1039. } __attribute__ ((__packed__));
  1040. struct offset_v2 {
  1041. __le64 v;
  1042. } __attribute__ ((__packed__));
  1043. static inline __u16 offset_v2_k_type(const struct offset_v2 *v2)
  1044. {
  1045. __u8 type = le64_to_cpu(v2->v) >> 60;
  1046. return (type <= TYPE_MAXTYPE) ? type : TYPE_ANY;
  1047. }
  1048. static inline void set_offset_v2_k_type(struct offset_v2 *v2, int type)
  1049. {
  1050. v2->v =
  1051. (v2->v & cpu_to_le64(~0ULL >> 4)) | cpu_to_le64((__u64) type << 60);
  1052. }
  1053. static inline loff_t offset_v2_k_offset(const struct offset_v2 *v2)
  1054. {
  1055. return le64_to_cpu(v2->v) & (~0ULL >> 4);
  1056. }
  1057. static inline void set_offset_v2_k_offset(struct offset_v2 *v2, loff_t offset)
  1058. {
  1059. offset &= (~0ULL >> 4);
  1060. v2->v = (v2->v & cpu_to_le64(15ULL << 60)) | cpu_to_le64(offset);
  1061. }
  1062. /*
  1063. * Key of an item determines its location in the S+tree, and
  1064. * is composed of 4 components
  1065. */
  1066. struct reiserfs_key {
  1067. /* packing locality: by default parent directory object id */
  1068. __le32 k_dir_id;
  1069. __le32 k_objectid; /* object identifier */
  1070. union {
  1071. struct offset_v1 k_offset_v1;
  1072. struct offset_v2 k_offset_v2;
  1073. } __attribute__ ((__packed__)) u;
  1074. } __attribute__ ((__packed__));
  1075. struct in_core_key {
  1076. /* packing locality: by default parent directory object id */
  1077. __u32 k_dir_id;
  1078. __u32 k_objectid; /* object identifier */
  1079. __u64 k_offset;
  1080. __u8 k_type;
  1081. };
  1082. struct cpu_key {
  1083. struct in_core_key on_disk_key;
  1084. int version;
  1085. /* 3 in all cases but direct2indirect and indirect2direct conversion */
  1086. int key_length;
  1087. };
  1088. /*
  1089. * Our function for comparing keys can compare keys of different
  1090. * lengths. It takes as a parameter the length of the keys it is to
  1091. * compare. These defines are used in determining what is to be passed
  1092. * to it as that parameter.
  1093. */
  1094. #define REISERFS_FULL_KEY_LEN 4
  1095. #define REISERFS_SHORT_KEY_LEN 2
  1096. /* The result of the key compare */
  1097. #define FIRST_GREATER 1
  1098. #define SECOND_GREATER -1
  1099. #define KEYS_IDENTICAL 0
  1100. #define KEY_FOUND 1
  1101. #define KEY_NOT_FOUND 0
  1102. #define KEY_SIZE (sizeof(struct reiserfs_key))
  1103. #define SHORT_KEY_SIZE (sizeof (__u32) + sizeof (__u32))
  1104. /* return values for search_by_key and clones */
  1105. #define ITEM_FOUND 1
  1106. #define ITEM_NOT_FOUND 0
  1107. #define ENTRY_FOUND 1
  1108. #define ENTRY_NOT_FOUND 0
  1109. #define DIRECTORY_NOT_FOUND -1
  1110. #define REGULAR_FILE_FOUND -2
  1111. #define DIRECTORY_FOUND -3
  1112. #define BYTE_FOUND 1
  1113. #define BYTE_NOT_FOUND 0
  1114. #define FILE_NOT_FOUND -1
  1115. #define POSITION_FOUND 1
  1116. #define POSITION_NOT_FOUND 0
  1117. /* return values for reiserfs_find_entry and search_by_entry_key */
  1118. #define NAME_FOUND 1
  1119. #define NAME_NOT_FOUND 0
  1120. #define GOTO_PREVIOUS_ITEM 2
  1121. #define NAME_FOUND_INVISIBLE 3
  1122. /*
  1123. * Everything in the filesystem is stored as a set of items. The
  1124. * item head contains the key of the item, its free space (for
  1125. * indirect items) and specifies the location of the item itself
  1126. * within the block.
  1127. */
  1128. struct item_head {
  1129. /*
  1130. * Everything in the tree is found by searching for it based on
  1131. * its key.
  1132. */
  1133. struct reiserfs_key ih_key;
  1134. union {
  1135. /*
  1136. * The free space in the last unformatted node of an
  1137. * indirect item if this is an indirect item. This
  1138. * equals 0xFFFF iff this is a direct item or stat data
  1139. * item. Note that the key, not this field, is used to
  1140. * determine the item type, and thus which field this
  1141. * union contains.
  1142. */
  1143. __le16 ih_free_space_reserved;
  1144. /*
  1145. * Iff this is a directory item, this field equals the
  1146. * number of directory entries in the directory item.
  1147. */
  1148. __le16 ih_entry_count;
  1149. } __attribute__ ((__packed__)) u;
  1150. __le16 ih_item_len; /* total size of the item body */
  1151. /* an offset to the item body within the block */
  1152. __le16 ih_item_location;
  1153. /*
  1154. * 0 for all old items, 2 for new ones. Highest bit is set by fsck
  1155. * temporary, cleaned after all done
  1156. */
  1157. __le16 ih_version;
  1158. } __attribute__ ((__packed__));
  1159. /* size of item header */
  1160. #define IH_SIZE (sizeof(struct item_head))
  1161. #define ih_free_space(ih) le16_to_cpu((ih)->u.ih_free_space_reserved)
  1162. #define ih_version(ih) le16_to_cpu((ih)->ih_version)
  1163. #define ih_entry_count(ih) le16_to_cpu((ih)->u.ih_entry_count)
  1164. #define ih_location(ih) le16_to_cpu((ih)->ih_item_location)
  1165. #define ih_item_len(ih) le16_to_cpu((ih)->ih_item_len)
  1166. #define put_ih_free_space(ih, val) do { (ih)->u.ih_free_space_reserved = cpu_to_le16(val); } while(0)
  1167. #define put_ih_version(ih, val) do { (ih)->ih_version = cpu_to_le16(val); } while (0)
  1168. #define put_ih_entry_count(ih, val) do { (ih)->u.ih_entry_count = cpu_to_le16(val); } while (0)
  1169. #define put_ih_location(ih, val) do { (ih)->ih_item_location = cpu_to_le16(val); } while (0)
  1170. #define put_ih_item_len(ih, val) do { (ih)->ih_item_len = cpu_to_le16(val); } while (0)
  1171. #define unreachable_item(ih) (ih_version(ih) & (1 << 15))
  1172. #define get_ih_free_space(ih) (ih_version (ih) == KEY_FORMAT_3_6 ? 0 : ih_free_space (ih))
  1173. #define set_ih_free_space(ih,val) put_ih_free_space((ih), ((ih_version(ih) == KEY_FORMAT_3_6) ? 0 : (val)))
  1174. /*
  1175. * these operate on indirect items, where you've got an array of ints
  1176. * at a possibly unaligned location. These are a noop on ia32
  1177. *
  1178. * p is the array of __u32, i is the index into the array, v is the value
  1179. * to store there.
  1180. */
  1181. #define get_block_num(p, i) get_unaligned_le32((p) + (i))
  1182. #define put_block_num(p, i, v) put_unaligned_le32((v), (p) + (i))
  1183. /* * in old version uniqueness field shows key type */
  1184. #define V1_SD_UNIQUENESS 0
  1185. #define V1_INDIRECT_UNIQUENESS 0xfffffffe
  1186. #define V1_DIRECT_UNIQUENESS 0xffffffff
  1187. #define V1_DIRENTRY_UNIQUENESS 500
  1188. #define V1_ANY_UNIQUENESS 555 /* FIXME: comment is required */
  1189. /* here are conversion routines */
  1190. static inline int uniqueness2type(__u32 uniqueness) CONSTF;
  1191. static inline int uniqueness2type(__u32 uniqueness)
  1192. {
  1193. switch ((int)uniqueness) {
  1194. case V1_SD_UNIQUENESS:
  1195. return TYPE_STAT_DATA;
  1196. case V1_INDIRECT_UNIQUENESS:
  1197. return TYPE_INDIRECT;
  1198. case V1_DIRECT_UNIQUENESS:
  1199. return TYPE_DIRECT;
  1200. case V1_DIRENTRY_UNIQUENESS:
  1201. return TYPE_DIRENTRY;
  1202. case V1_ANY_UNIQUENESS:
  1203. default:
  1204. return TYPE_ANY;
  1205. }
  1206. }
  1207. static inline __u32 type2uniqueness(int type) CONSTF;
  1208. static inline __u32 type2uniqueness(int type)
  1209. {
  1210. switch (type) {
  1211. case TYPE_STAT_DATA:
  1212. return V1_SD_UNIQUENESS;
  1213. case TYPE_INDIRECT:
  1214. return V1_INDIRECT_UNIQUENESS;
  1215. case TYPE_DIRECT:
  1216. return V1_DIRECT_UNIQUENESS;
  1217. case TYPE_DIRENTRY:
  1218. return V1_DIRENTRY_UNIQUENESS;
  1219. case TYPE_ANY:
  1220. default:
  1221. return V1_ANY_UNIQUENESS;
  1222. }
  1223. }
  1224. /*
  1225. * key is pointer to on disk key which is stored in le, result is cpu,
  1226. * there is no way to get version of object from key, so, provide
  1227. * version to these defines
  1228. */
  1229. static inline loff_t le_key_k_offset(int version,
  1230. const struct reiserfs_key *key)
  1231. {
  1232. return (version == KEY_FORMAT_3_5) ?
  1233. le32_to_cpu(key->u.k_offset_v1.k_offset) :
  1234. offset_v2_k_offset(&(key->u.k_offset_v2));
  1235. }
  1236. static inline loff_t le_ih_k_offset(const struct item_head *ih)
  1237. {
  1238. return le_key_k_offset(ih_version(ih), &(ih->ih_key));
  1239. }
  1240. static inline loff_t le_key_k_type(int version, const struct reiserfs_key *key)
  1241. {
  1242. if (version == KEY_FORMAT_3_5) {
  1243. loff_t val = le32_to_cpu(key->u.k_offset_v1.k_uniqueness);
  1244. return uniqueness2type(val);
  1245. } else
  1246. return offset_v2_k_type(&(key->u.k_offset_v2));
  1247. }
  1248. static inline loff_t le_ih_k_type(const struct item_head *ih)
  1249. {
  1250. return le_key_k_type(ih_version(ih), &(ih->ih_key));
  1251. }
  1252. static inline void set_le_key_k_offset(int version, struct reiserfs_key *key,
  1253. loff_t offset)
  1254. {
  1255. if (version == KEY_FORMAT_3_5)
  1256. key->u.k_offset_v1.k_offset = cpu_to_le32(offset);
  1257. else
  1258. set_offset_v2_k_offset(&key->u.k_offset_v2, offset);
  1259. }
  1260. static inline void add_le_key_k_offset(int version, struct reiserfs_key *key,
  1261. loff_t offset)
  1262. {
  1263. set_le_key_k_offset(version, key,
  1264. le_key_k_offset(version, key) + offset);
  1265. }
  1266. static inline void add_le_ih_k_offset(struct item_head *ih, loff_t offset)
  1267. {
  1268. add_le_key_k_offset(ih_version(ih), &(ih->ih_key), offset);
  1269. }
  1270. static inline void set_le_ih_k_offset(struct item_head *ih, loff_t offset)
  1271. {
  1272. set_le_key_k_offset(ih_version(ih), &(ih->ih_key), offset);
  1273. }
  1274. static inline void set_le_key_k_type(int version, struct reiserfs_key *key,
  1275. int type)
  1276. {
  1277. if (version == KEY_FORMAT_3_5) {
  1278. type = type2uniqueness(type);
  1279. key->u.k_offset_v1.k_uniqueness = cpu_to_le32(type);
  1280. } else
  1281. set_offset_v2_k_type(&key->u.k_offset_v2, type);
  1282. }
  1283. static inline void set_le_ih_k_type(struct item_head *ih, int type)
  1284. {
  1285. set_le_key_k_type(ih_version(ih), &(ih->ih_key), type);
  1286. }
  1287. static inline int is_direntry_le_key(int version, struct reiserfs_key *key)
  1288. {
  1289. return le_key_k_type(version, key) == TYPE_DIRENTRY;
  1290. }
  1291. static inline int is_direct_le_key(int version, struct reiserfs_key *key)
  1292. {
  1293. return le_key_k_type(version, key) == TYPE_DIRECT;
  1294. }
  1295. static inline int is_indirect_le_key(int version, struct reiserfs_key *key)
  1296. {
  1297. return le_key_k_type(version, key) == TYPE_INDIRECT;
  1298. }
  1299. static inline int is_statdata_le_key(int version, struct reiserfs_key *key)
  1300. {
  1301. return le_key_k_type(version, key) == TYPE_STAT_DATA;
  1302. }
  1303. /* item header has version. */
  1304. static inline int is_direntry_le_ih(struct item_head *ih)
  1305. {
  1306. return is_direntry_le_key(ih_version(ih), &ih->ih_key);
  1307. }
  1308. static inline int is_direct_le_ih(struct item_head *ih)
  1309. {
  1310. return is_direct_le_key(ih_version(ih), &ih->ih_key);
  1311. }
  1312. static inline int is_indirect_le_ih(struct item_head *ih)
  1313. {
  1314. return is_indirect_le_key(ih_version(ih), &ih->ih_key);
  1315. }
  1316. static inline int is_statdata_le_ih(struct item_head *ih)
  1317. {
  1318. return is_statdata_le_key(ih_version(ih), &ih->ih_key);
  1319. }
  1320. /* key is pointer to cpu key, result is cpu */
  1321. static inline loff_t cpu_key_k_offset(const struct cpu_key *key)
  1322. {
  1323. return key->on_disk_key.k_offset;
  1324. }
  1325. static inline loff_t cpu_key_k_type(const struct cpu_key *key)
  1326. {
  1327. return key->on_disk_key.k_type;
  1328. }
  1329. static inline void set_cpu_key_k_offset(struct cpu_key *key, loff_t offset)
  1330. {
  1331. key->on_disk_key.k_offset = offset;
  1332. }
  1333. static inline void set_cpu_key_k_type(struct cpu_key *key, int type)
  1334. {
  1335. key->on_disk_key.k_type = type;
  1336. }
  1337. static inline void cpu_key_k_offset_dec(struct cpu_key *key)
  1338. {
  1339. key->on_disk_key.k_offset--;
  1340. }
  1341. #define is_direntry_cpu_key(key) (cpu_key_k_type (key) == TYPE_DIRENTRY)
  1342. #define is_direct_cpu_key(key) (cpu_key_k_type (key) == TYPE_DIRECT)
  1343. #define is_indirect_cpu_key(key) (cpu_key_k_type (key) == TYPE_INDIRECT)
  1344. #define is_statdata_cpu_key(key) (cpu_key_k_type (key) == TYPE_STAT_DATA)
  1345. /* are these used ? */
  1346. #define is_direntry_cpu_ih(ih) (is_direntry_cpu_key (&((ih)->ih_key)))
  1347. #define is_direct_cpu_ih(ih) (is_direct_cpu_key (&((ih)->ih_key)))
  1348. #define is_indirect_cpu_ih(ih) (is_indirect_cpu_key (&((ih)->ih_key)))
  1349. #define is_statdata_cpu_ih(ih) (is_statdata_cpu_key (&((ih)->ih_key)))
  1350. #define I_K_KEY_IN_ITEM(ih, key, n_blocksize) \
  1351. (!COMP_SHORT_KEYS(ih, key) && \
  1352. I_OFF_BYTE_IN_ITEM(ih, k_offset(key), n_blocksize))
  1353. /* maximal length of item */
  1354. #define MAX_ITEM_LEN(block_size) (block_size - BLKH_SIZE - IH_SIZE)
  1355. #define MIN_ITEM_LEN 1
  1356. /* object identifier for root dir */
  1357. #define REISERFS_ROOT_OBJECTID 2
  1358. #define REISERFS_ROOT_PARENT_OBJECTID 1
  1359. extern struct reiserfs_key root_key;
  1360. /*
  1361. * Picture represents a leaf of the S+tree
  1362. * ______________________________________________________
  1363. * | | Array of | | |
  1364. * |Block | Object-Item | F r e e | Objects- |
  1365. * | head | Headers | S p a c e | Items |
  1366. * |______|_______________|___________________|___________|
  1367. */
  1368. /*
  1369. * Header of a disk block. More precisely, header of a formatted leaf
  1370. * or internal node, and not the header of an unformatted node.
  1371. */
  1372. struct block_head {
  1373. __le16 blk_level; /* Level of a block in the tree. */
  1374. __le16 blk_nr_item; /* Number of keys/items in a block. */
  1375. __le16 blk_free_space; /* Block free space in bytes. */
  1376. __le16 blk_reserved;
  1377. /* dump this in v4/planA */
  1378. /* kept only for compatibility */
  1379. struct reiserfs_key blk_right_delim_key;
  1380. };
  1381. #define BLKH_SIZE (sizeof(struct block_head))
  1382. #define blkh_level(p_blkh) (le16_to_cpu((p_blkh)->blk_level))
  1383. #define blkh_nr_item(p_blkh) (le16_to_cpu((p_blkh)->blk_nr_item))
  1384. #define blkh_free_space(p_blkh) (le16_to_cpu((p_blkh)->blk_free_space))
  1385. #define blkh_reserved(p_blkh) (le16_to_cpu((p_blkh)->blk_reserved))
  1386. #define set_blkh_level(p_blkh,val) ((p_blkh)->blk_level = cpu_to_le16(val))
  1387. #define set_blkh_nr_item(p_blkh,val) ((p_blkh)->blk_nr_item = cpu_to_le16(val))
  1388. #define set_blkh_free_space(p_blkh,val) ((p_blkh)->blk_free_space = cpu_to_le16(val))
  1389. #define set_blkh_reserved(p_blkh,val) ((p_blkh)->blk_reserved = cpu_to_le16(val))
  1390. #define blkh_right_delim_key(p_blkh) ((p_blkh)->blk_right_delim_key)
  1391. #define set_blkh_right_delim_key(p_blkh,val) ((p_blkh)->blk_right_delim_key = val)
  1392. /* values for blk_level field of the struct block_head */
  1393. /*
  1394. * When node gets removed from the tree its blk_level is set to FREE_LEVEL.
  1395. * It is then used to see whether the node is still in the tree
  1396. */
  1397. #define FREE_LEVEL 0
  1398. #define DISK_LEAF_NODE_LEVEL 1 /* Leaf node level. */
  1399. /*
  1400. * Given the buffer head of a formatted node, resolve to the
  1401. * block head of that node.
  1402. */
  1403. #define B_BLK_HEAD(bh) ((struct block_head *)((bh)->b_data))
  1404. /* Number of items that are in buffer. */
  1405. #define B_NR_ITEMS(bh) (blkh_nr_item(B_BLK_HEAD(bh)))
  1406. #define B_LEVEL(bh) (blkh_level(B_BLK_HEAD(bh)))
  1407. #define B_FREE_SPACE(bh) (blkh_free_space(B_BLK_HEAD(bh)))
  1408. #define PUT_B_NR_ITEMS(bh, val) do { set_blkh_nr_item(B_BLK_HEAD(bh), val); } while (0)
  1409. #define PUT_B_LEVEL(bh, val) do { set_blkh_level(B_BLK_HEAD(bh), val); } while (0)
  1410. #define PUT_B_FREE_SPACE(bh, val) do { set_blkh_free_space(B_BLK_HEAD(bh), val); } while (0)
  1411. /* Get right delimiting key. -- little endian */
  1412. #define B_PRIGHT_DELIM_KEY(bh) (&(blk_right_delim_key(B_BLK_HEAD(bh))))
  1413. /* Does the buffer contain a disk leaf. */
  1414. #define B_IS_ITEMS_LEVEL(bh) (B_LEVEL(bh) == DISK_LEAF_NODE_LEVEL)
  1415. /* Does the buffer contain a disk internal node */
  1416. #define B_IS_KEYS_LEVEL(bh) (B_LEVEL(bh) > DISK_LEAF_NODE_LEVEL \
  1417. && B_LEVEL(bh) <= MAX_HEIGHT)
  1418. /***************************************************************************
  1419. * STAT DATA *
  1420. ***************************************************************************/
  1421. /*
  1422. * old stat data is 32 bytes long. We are going to distinguish new one by
  1423. * different size
  1424. */
  1425. struct stat_data_v1 {
  1426. __le16 sd_mode; /* file type, permissions */
  1427. __le16 sd_nlink; /* number of hard links */
  1428. __le16 sd_uid; /* owner */
  1429. __le16 sd_gid; /* group */
  1430. __le32 sd_size; /* file size */
  1431. __le32 sd_atime; /* time of last access */
  1432. __le32 sd_mtime; /* time file was last modified */
  1433. /*
  1434. * time inode (stat data) was last changed
  1435. * (except changes to sd_atime and sd_mtime)
  1436. */
  1437. __le32 sd_ctime;
  1438. union {
  1439. __le32 sd_rdev;
  1440. __le32 sd_blocks; /* number of blocks file uses */
  1441. } __attribute__ ((__packed__)) u;
  1442. /*
  1443. * first byte of file which is stored in a direct item: except that if
  1444. * it equals 1 it is a symlink and if it equals ~(__u32)0 there is no
  1445. * direct item. The existence of this field really grates on me.
  1446. * Let's replace it with a macro based on sd_size and our tail
  1447. * suppression policy. Someday. -Hans
  1448. */
  1449. __le32 sd_first_direct_byte;
  1450. } __attribute__ ((__packed__));
  1451. #define SD_V1_SIZE (sizeof(struct stat_data_v1))
  1452. #define stat_data_v1(ih) (ih_version (ih) == KEY_FORMAT_3_5)
  1453. #define sd_v1_mode(sdp) (le16_to_cpu((sdp)->sd_mode))
  1454. #define set_sd_v1_mode(sdp,v) ((sdp)->sd_mode = cpu_to_le16(v))
  1455. #define sd_v1_nlink(sdp) (le16_to_cpu((sdp)->sd_nlink))
  1456. #define set_sd_v1_nlink(sdp,v) ((sdp)->sd_nlink = cpu_to_le16(v))
  1457. #define sd_v1_uid(sdp) (le16_to_cpu((sdp)->sd_uid))
  1458. #define set_sd_v1_uid(sdp,v) ((sdp)->sd_uid = cpu_to_le16(v))
  1459. #define sd_v1_gid(sdp) (le16_to_cpu((sdp)->sd_gid))
  1460. #define set_sd_v1_gid(sdp,v) ((sdp)->sd_gid = cpu_to_le16(v))
  1461. #define sd_v1_size(sdp) (le32_to_cpu((sdp)->sd_size))
  1462. #define set_sd_v1_size(sdp,v) ((sdp)->sd_size = cpu_to_le32(v))
  1463. #define sd_v1_atime(sdp) (le32_to_cpu((sdp)->sd_atime))
  1464. #define set_sd_v1_atime(sdp,v) ((sdp)->sd_atime = cpu_to_le32(v))
  1465. #define sd_v1_mtime(sdp) (le32_to_cpu((sdp)->sd_mtime))
  1466. #define set_sd_v1_mtime(sdp,v) ((sdp)->sd_mtime = cpu_to_le32(v))
  1467. #define sd_v1_ctime(sdp) (le32_to_cpu((sdp)->sd_ctime))
  1468. #define set_sd_v1_ctime(sdp,v) ((sdp)->sd_ctime = cpu_to_le32(v))
  1469. #define sd_v1_rdev(sdp) (le32_to_cpu((sdp)->u.sd_rdev))
  1470. #define set_sd_v1_rdev(sdp,v) ((sdp)->u.sd_rdev = cpu_to_le32(v))
  1471. #define sd_v1_blocks(sdp) (le32_to_cpu((sdp)->u.sd_blocks))
  1472. #define set_sd_v1_blocks(sdp,v) ((sdp)->u.sd_blocks = cpu_to_le32(v))
  1473. #define sd_v1_first_direct_byte(sdp) \
  1474. (le32_to_cpu((sdp)->sd_first_direct_byte))
  1475. #define set_sd_v1_first_direct_byte(sdp,v) \
  1476. ((sdp)->sd_first_direct_byte = cpu_to_le32(v))
  1477. /* inode flags stored in sd_attrs (nee sd_reserved) */
  1478. /*
  1479. * we want common flags to have the same values as in ext2,
  1480. * so chattr(1) will work without problems
  1481. */
  1482. #define REISERFS_IMMUTABLE_FL FS_IMMUTABLE_FL
  1483. #define REISERFS_APPEND_FL FS_APPEND_FL
  1484. #define REISERFS_SYNC_FL FS_SYNC_FL
  1485. #define REISERFS_NOATIME_FL FS_NOATIME_FL
  1486. #define REISERFS_NODUMP_FL FS_NODUMP_FL
  1487. #define REISERFS_SECRM_FL FS_SECRM_FL
  1488. #define REISERFS_UNRM_FL FS_UNRM_FL
  1489. #define REISERFS_COMPR_FL FS_COMPR_FL
  1490. #define REISERFS_NOTAIL_FL FS_NOTAIL_FL
  1491. /* persistent flags that file inherits from the parent directory */
  1492. #define REISERFS_INHERIT_MASK ( REISERFS_IMMUTABLE_FL | \
  1493. REISERFS_SYNC_FL | \
  1494. REISERFS_NOATIME_FL | \
  1495. REISERFS_NODUMP_FL | \
  1496. REISERFS_SECRM_FL | \
  1497. REISERFS_COMPR_FL | \
  1498. REISERFS_NOTAIL_FL )
  1499. /*
  1500. * Stat Data on disk (reiserfs version of UFS disk inode minus the
  1501. * address blocks)
  1502. */
  1503. struct stat_data {
  1504. __le16 sd_mode; /* file type, permissions */
  1505. __le16 sd_attrs; /* persistent inode flags */
  1506. __le32 sd_nlink; /* number of hard links */
  1507. __le64 sd_size; /* file size */
  1508. __le32 sd_uid; /* owner */
  1509. __le32 sd_gid; /* group */
  1510. __le32 sd_atime; /* time of last access */
  1511. __le32 sd_mtime; /* time file was last modified */
  1512. /*
  1513. * time inode (stat data) was last changed
  1514. * (except changes to sd_atime and sd_mtime)
  1515. */
  1516. __le32 sd_ctime;
  1517. __le32 sd_blocks;
  1518. union {
  1519. __le32 sd_rdev;
  1520. __le32 sd_generation;
  1521. } __attribute__ ((__packed__)) u;
  1522. } __attribute__ ((__packed__));
  1523. /* this is 44 bytes long */
  1524. #define SD_SIZE (sizeof(struct stat_data))
  1525. #define SD_V2_SIZE SD_SIZE
  1526. #define stat_data_v2(ih) (ih_version (ih) == KEY_FORMAT_3_6)
  1527. #define sd_v2_mode(sdp) (le16_to_cpu((sdp)->sd_mode))
  1528. #define set_sd_v2_mode(sdp,v) ((sdp)->sd_mode = cpu_to_le16(v))
  1529. /* sd_reserved */
  1530. /* set_sd_reserved */
  1531. #define sd_v2_nlink(sdp) (le32_to_cpu((sdp)->sd_nlink))
  1532. #define set_sd_v2_nlink(sdp,v) ((sdp)->sd_nlink = cpu_to_le32(v))
  1533. #define sd_v2_size(sdp) (le64_to_cpu((sdp)->sd_size))
  1534. #define set_sd_v2_size(sdp,v) ((sdp)->sd_size = cpu_to_le64(v))
  1535. #define sd_v2_uid(sdp) (le32_to_cpu((sdp)->sd_uid))
  1536. #define set_sd_v2_uid(sdp,v) ((sdp)->sd_uid = cpu_to_le32(v))
  1537. #define sd_v2_gid(sdp) (le32_to_cpu((sdp)->sd_gid))
  1538. #define set_sd_v2_gid(sdp,v) ((sdp)->sd_gid = cpu_to_le32(v))
  1539. #define sd_v2_atime(sdp) (le32_to_cpu((sdp)->sd_atime))
  1540. #define set_sd_v2_atime(sdp,v) ((sdp)->sd_atime = cpu_to_le32(v))
  1541. #define sd_v2_mtime(sdp) (le32_to_cpu((sdp)->sd_mtime))
  1542. #define set_sd_v2_mtime(sdp,v) ((sdp)->sd_mtime = cpu_to_le32(v))
  1543. #define sd_v2_ctime(sdp) (le32_to_cpu((sdp)->sd_ctime))
  1544. #define set_sd_v2_ctime(sdp,v) ((sdp)->sd_ctime = cpu_to_le32(v))
  1545. #define sd_v2_blocks(sdp) (le32_to_cpu((sdp)->sd_blocks))
  1546. #define set_sd_v2_blocks(sdp,v) ((sdp)->sd_blocks = cpu_to_le32(v))
  1547. #define sd_v2_rdev(sdp) (le32_to_cpu((sdp)->u.sd_rdev))
  1548. #define set_sd_v2_rdev(sdp,v) ((sdp)->u.sd_rdev = cpu_to_le32(v))
  1549. #define sd_v2_generation(sdp) (le32_to_cpu((sdp)->u.sd_generation))
  1550. #define set_sd_v2_generation(sdp,v) ((sdp)->u.sd_generation = cpu_to_le32(v))
  1551. #define sd_v2_attrs(sdp) (le16_to_cpu((sdp)->sd_attrs))
  1552. #define set_sd_v2_attrs(sdp,v) ((sdp)->sd_attrs = cpu_to_le16(v))
  1553. /***************************************************************************
  1554. * DIRECTORY STRUCTURE *
  1555. ***************************************************************************/
  1556. /*
  1557. * Picture represents the structure of directory items
  1558. * ________________________________________________
  1559. * | Array of | | | | | |
  1560. * | directory |N-1| N-2 | .... | 1st |0th|
  1561. * | entry headers | | | | | |
  1562. * |_______________|___|_____|________|_______|___|
  1563. * <---- directory entries ------>
  1564. *
  1565. * First directory item has k_offset component 1. We store "." and ".."
  1566. * in one item, always, we never split "." and ".." into differing
  1567. * items. This makes, among other things, the code for removing
  1568. * directories simpler.
  1569. */
  1570. #define SD_OFFSET 0
  1571. #define SD_UNIQUENESS 0
  1572. #define DOT_OFFSET 1
  1573. #define DOT_DOT_OFFSET 2
  1574. #define DIRENTRY_UNIQUENESS 500
  1575. #define FIRST_ITEM_OFFSET 1
  1576. /*
  1577. * Q: How to get key of object pointed to by entry from entry?
  1578. *
  1579. * A: Each directory entry has its header. This header has deh_dir_id
  1580. * and deh_objectid fields, those are key of object, entry points to
  1581. */
  1582. /*
  1583. * NOT IMPLEMENTED:
  1584. * Directory will someday contain stat data of object
  1585. */
  1586. struct reiserfs_de_head {
  1587. __le32 deh_offset; /* third component of the directory entry key */
  1588. /*
  1589. * objectid of the parent directory of the object, that is referenced
  1590. * by directory entry
  1591. */
  1592. __le32 deh_dir_id;
  1593. /* objectid of the object, that is referenced by directory entry */
  1594. __le32 deh_objectid;
  1595. __le16 deh_location; /* offset of name in the whole item */
  1596. /*
  1597. * whether 1) entry contains stat data (for future), and
  1598. * 2) whether entry is hidden (unlinked)
  1599. */
  1600. __le16 deh_state;
  1601. } __attribute__ ((__packed__));
  1602. #define DEH_SIZE sizeof(struct reiserfs_de_head)
  1603. #define deh_offset(p_deh) (le32_to_cpu((p_deh)->deh_offset))
  1604. #define deh_dir_id(p_deh) (le32_to_cpu((p_deh)->deh_dir_id))
  1605. #define deh_objectid(p_deh) (le32_to_cpu((p_deh)->deh_objectid))
  1606. #define deh_location(p_deh) (le16_to_cpu((p_deh)->deh_location))
  1607. #define deh_state(p_deh) (le16_to_cpu((p_deh)->deh_state))
  1608. #define put_deh_offset(p_deh,v) ((p_deh)->deh_offset = cpu_to_le32((v)))
  1609. #define put_deh_dir_id(p_deh,v) ((p_deh)->deh_dir_id = cpu_to_le32((v)))
  1610. #define put_deh_objectid(p_deh,v) ((p_deh)->deh_objectid = cpu_to_le32((v)))
  1611. #define put_deh_location(p_deh,v) ((p_deh)->deh_location = cpu_to_le16((v)))
  1612. #define put_deh_state(p_deh,v) ((p_deh)->deh_state = cpu_to_le16((v)))
  1613. /* empty directory contains two entries "." and ".." and their headers */
  1614. #define EMPTY_DIR_SIZE \
  1615. (DEH_SIZE * 2 + ROUND_UP (strlen (".")) + ROUND_UP (strlen ("..")))
  1616. /* old format directories have this size when empty */
  1617. #define EMPTY_DIR_SIZE_V1 (DEH_SIZE * 2 + 3)
  1618. #define DEH_Statdata 0 /* not used now */
  1619. #define DEH_Visible 2
  1620. /* 64 bit systems (and the S/390) need to be aligned explicitly -jdm */
  1621. #if BITS_PER_LONG == 64 || defined(__s390__) || defined(__hppa__)
  1622. # define ADDR_UNALIGNED_BITS (3)
  1623. #endif
  1624. /*
  1625. * These are only used to manipulate deh_state.
  1626. * Because of this, we'll use the ext2_ bit routines,
  1627. * since they are little endian
  1628. */
  1629. #ifdef ADDR_UNALIGNED_BITS
  1630. # define aligned_address(addr) ((void *)((long)(addr) & ~((1UL << ADDR_UNALIGNED_BITS) - 1)))
  1631. # define unaligned_offset(addr) (((int)((long)(addr) & ((1 << ADDR_UNALIGNED_BITS) - 1))) << 3)
  1632. # define set_bit_unaligned(nr, addr) \
  1633. __test_and_set_bit_le((nr) + unaligned_offset(addr), aligned_address(addr))
  1634. # define clear_bit_unaligned(nr, addr) \
  1635. __test_and_clear_bit_le((nr) + unaligned_offset(addr), aligned_address(addr))
  1636. # define test_bit_unaligned(nr, addr) \
  1637. test_bit_le((nr) + unaligned_offset(addr), aligned_address(addr))
  1638. #else
  1639. # define set_bit_unaligned(nr, addr) __test_and_set_bit_le(nr, addr)
  1640. # define clear_bit_unaligned(nr, addr) __test_and_clear_bit_le(nr, addr)
  1641. # define test_bit_unaligned(nr, addr) test_bit_le(nr, addr)
  1642. #endif
  1643. #define mark_de_with_sd(deh) set_bit_unaligned (DEH_Statdata, &((deh)->deh_state))
  1644. #define mark_de_without_sd(deh) clear_bit_unaligned (DEH_Statdata, &((deh)->deh_state))
  1645. #define mark_de_visible(deh) set_bit_unaligned (DEH_Visible, &((deh)->deh_state))
  1646. #define mark_de_hidden(deh) clear_bit_unaligned (DEH_Visible, &((deh)->deh_state))
  1647. #define de_with_sd(deh) test_bit_unaligned (DEH_Statdata, &((deh)->deh_state))
  1648. #define de_visible(deh) test_bit_unaligned (DEH_Visible, &((deh)->deh_state))
  1649. #define de_hidden(deh) !test_bit_unaligned (DEH_Visible, &((deh)->deh_state))
  1650. extern void make_empty_dir_item_v1(char *body, __le32 dirid, __le32 objid,
  1651. __le32 par_dirid, __le32 par_objid);
  1652. extern void make_empty_dir_item(char *body, __le32 dirid, __le32 objid,
  1653. __le32 par_dirid, __le32 par_objid);
  1654. /* two entries per block (at least) */
  1655. #define REISERFS_MAX_NAME(block_size) 255
  1656. /*
  1657. * this structure is used for operations on directory entries. It is
  1658. * not a disk structure.
  1659. *
  1660. * When reiserfs_find_entry or search_by_entry_key find directory
  1661. * entry, they return filled reiserfs_dir_entry structure
  1662. */
  1663. struct reiserfs_dir_entry {
  1664. struct buffer_head *de_bh;
  1665. int de_item_num;
  1666. struct item_head *de_ih;
  1667. int de_entry_num;
  1668. struct reiserfs_de_head *de_deh;
  1669. int de_entrylen;
  1670. int de_namelen;
  1671. char *de_name;
  1672. unsigned long *de_gen_number_bit_string;
  1673. __u32 de_dir_id;
  1674. __u32 de_objectid;
  1675. struct cpu_key de_entry_key;
  1676. };
  1677. /*
  1678. * these defines are useful when a particular member of
  1679. * a reiserfs_dir_entry is needed
  1680. */
  1681. /* pointer to file name, stored in entry */
  1682. #define B_I_DEH_ENTRY_FILE_NAME(bh, ih, deh) \
  1683. (ih_item_body(bh, ih) + deh_location(deh))
  1684. /* length of name */
  1685. #define I_DEH_N_ENTRY_FILE_NAME_LENGTH(ih,deh,entry_num) \
  1686. (I_DEH_N_ENTRY_LENGTH (ih, deh, entry_num) - (de_with_sd (deh) ? SD_SIZE : 0))
  1687. /* hash value occupies bits from 7 up to 30 */
  1688. #define GET_HASH_VALUE(offset) ((offset) & 0x7fffff80LL)
  1689. /* generation number occupies 7 bits starting from 0 up to 6 */
  1690. #define GET_GENERATION_NUMBER(offset) ((offset) & 0x7fLL)
  1691. #define MAX_GENERATION_NUMBER 127
  1692. #define SET_GENERATION_NUMBER(offset,gen_number) (GET_HASH_VALUE(offset)|(gen_number))
  1693. /*
  1694. * Picture represents an internal node of the reiserfs tree
  1695. * ______________________________________________________
  1696. * | | Array of | Array of | Free |
  1697. * |block | keys | pointers | space |
  1698. * | head | N | N+1 | |
  1699. * |______|_______________|___________________|___________|
  1700. */
  1701. /***************************************************************************
  1702. * DISK CHILD *
  1703. ***************************************************************************/
  1704. /*
  1705. * Disk child pointer:
  1706. * The pointer from an internal node of the tree to a node that is on disk.
  1707. */
  1708. struct disk_child {
  1709. __le32 dc_block_number; /* Disk child's block number. */
  1710. __le16 dc_size; /* Disk child's used space. */
  1711. __le16 dc_reserved;
  1712. };
  1713. #define DC_SIZE (sizeof(struct disk_child))
  1714. #define dc_block_number(dc_p) (le32_to_cpu((dc_p)->dc_block_number))
  1715. #define dc_size(dc_p) (le16_to_cpu((dc_p)->dc_size))
  1716. #define put_dc_block_number(dc_p, val) do { (dc_p)->dc_block_number = cpu_to_le32(val); } while(0)
  1717. #define put_dc_size(dc_p, val) do { (dc_p)->dc_size = cpu_to_le16(val); } while(0)
  1718. /* Get disk child by buffer header and position in the tree node. */
  1719. #define B_N_CHILD(bh, n_pos) ((struct disk_child *)\
  1720. ((bh)->b_data + BLKH_SIZE + B_NR_ITEMS(bh) * KEY_SIZE + DC_SIZE * (n_pos)))
  1721. /* Get disk child number by buffer header and position in the tree node. */
  1722. #define B_N_CHILD_NUM(bh, n_pos) (dc_block_number(B_N_CHILD(bh, n_pos)))
  1723. #define PUT_B_N_CHILD_NUM(bh, n_pos, val) \
  1724. (put_dc_block_number(B_N_CHILD(bh, n_pos), val))
  1725. /* maximal value of field child_size in structure disk_child */
  1726. /* child size is the combined size of all items and their headers */
  1727. #define MAX_CHILD_SIZE(bh) ((int)( (bh)->b_size - BLKH_SIZE ))
  1728. /* amount of used space in buffer (not including block head) */
  1729. #define B_CHILD_SIZE(cur) (MAX_CHILD_SIZE(cur)-(B_FREE_SPACE(cur)))
  1730. /* max and min number of keys in internal node */
  1731. #define MAX_NR_KEY(bh) ( (MAX_CHILD_SIZE(bh)-DC_SIZE)/(KEY_SIZE+DC_SIZE) )
  1732. #define MIN_NR_KEY(bh) (MAX_NR_KEY(bh)/2)
  1733. /***************************************************************************
  1734. * PATH STRUCTURES AND DEFINES *
  1735. ***************************************************************************/
  1736. /*
  1737. * search_by_key fills up the path from the root to the leaf as it descends
  1738. * the tree looking for the key. It uses reiserfs_bread to try to find
  1739. * buffers in the cache given their block number. If it does not find
  1740. * them in the cache it reads them from disk. For each node search_by_key
  1741. * finds using reiserfs_bread it then uses bin_search to look through that
  1742. * node. bin_search will find the position of the block_number of the next
  1743. * node if it is looking through an internal node. If it is looking through
  1744. * a leaf node bin_search will find the position of the item which has key
  1745. * either equal to given key, or which is the maximal key less than the
  1746. * given key.
  1747. */
  1748. struct path_element {
  1749. /* Pointer to the buffer at the path in the tree. */
  1750. struct buffer_head *pe_buffer;
  1751. /* Position in the tree node which is placed in the buffer above. */
  1752. int pe_position;
  1753. };
  1754. /*
  1755. * maximal height of a tree. don't change this without
  1756. * changing JOURNAL_PER_BALANCE_CNT
  1757. */
  1758. #define MAX_HEIGHT 5
  1759. /* Must be equals MAX_HEIGHT + FIRST_PATH_ELEMENT_OFFSET */
  1760. #define EXTENDED_MAX_HEIGHT 7
  1761. /* Must be equal to at least 2. */
  1762. #define FIRST_PATH_ELEMENT_OFFSET 2
  1763. /* Must be equal to FIRST_PATH_ELEMENT_OFFSET - 1 */
  1764. #define ILLEGAL_PATH_ELEMENT_OFFSET 1
  1765. /* this MUST be MAX_HEIGHT + 1. See about FEB below */
  1766. #define MAX_FEB_SIZE 6
  1767. /*
  1768. * We need to keep track of who the ancestors of nodes are. When we
  1769. * perform a search we record which nodes were visited while
  1770. * descending the tree looking for the node we searched for. This list
  1771. * of nodes is called the path. This information is used while
  1772. * performing balancing. Note that this path information may become
  1773. * invalid, and this means we must check it when using it to see if it
  1774. * is still valid. You'll need to read search_by_key and the comments
  1775. * in it, especially about decrement_counters_in_path(), to understand
  1776. * this structure.
  1777. *
  1778. * Paths make the code so much harder to work with and debug.... An
  1779. * enormous number of bugs are due to them, and trying to write or modify
  1780. * code that uses them just makes my head hurt. They are based on an
  1781. * excessive effort to avoid disturbing the precious VFS code.:-( The
  1782. * gods only know how we are going to SMP the code that uses them.
  1783. * znodes are the way!
  1784. */
  1785. #define PATH_READA 0x1 /* do read ahead */
  1786. #define PATH_READA_BACK 0x2 /* read backwards */
  1787. struct treepath {
  1788. int path_length; /* Length of the array above. */
  1789. int reada;
  1790. /* Array of the path elements. */
  1791. struct path_element path_elements[EXTENDED_MAX_HEIGHT];
  1792. int pos_in_item;
  1793. };
  1794. #define pos_in_item(path) ((path)->pos_in_item)
  1795. #define INITIALIZE_PATH(var) \
  1796. struct treepath var = {.path_length = ILLEGAL_PATH_ELEMENT_OFFSET, .reada = 0,}
  1797. /* Get path element by path and path position. */
  1798. #define PATH_OFFSET_PELEMENT(path, n_offset) ((path)->path_elements + (n_offset))
  1799. /* Get buffer header at the path by path and path position. */
  1800. #define PATH_OFFSET_PBUFFER(path, n_offset) (PATH_OFFSET_PELEMENT(path, n_offset)->pe_buffer)
  1801. /* Get position in the element at the path by path and path position. */
  1802. #define PATH_OFFSET_POSITION(path, n_offset) (PATH_OFFSET_PELEMENT(path, n_offset)->pe_position)
  1803. #define PATH_PLAST_BUFFER(path) (PATH_OFFSET_PBUFFER((path), (path)->path_length))
  1804. /*
  1805. * you know, to the person who didn't write this the macro name does not
  1806. * at first suggest what it does. Maybe POSITION_FROM_PATH_END? Or
  1807. * maybe we should just focus on dumping paths... -Hans
  1808. */
  1809. #define PATH_LAST_POSITION(path) (PATH_OFFSET_POSITION((path), (path)->path_length))
  1810. /*
  1811. * in do_balance leaf has h == 0 in contrast with path structure,
  1812. * where root has level == 0. That is why we need these defines
  1813. */
  1814. /* tb->S[h] */
  1815. #define PATH_H_PBUFFER(path, h) \
  1816. PATH_OFFSET_PBUFFER(path, path->path_length - (h))
  1817. /* tb->F[h] or tb->S[0]->b_parent */
  1818. #define PATH_H_PPARENT(path, h) PATH_H_PBUFFER(path, (h) + 1)
  1819. #define PATH_H_POSITION(path, h) \
  1820. PATH_OFFSET_POSITION(path, path->path_length - (h))
  1821. /* tb->S[h]->b_item_order */
  1822. #define PATH_H_B_ITEM_ORDER(path, h) PATH_H_POSITION(path, h + 1)
  1823. #define PATH_H_PATH_OFFSET(path, n_h) ((path)->path_length - (n_h))
  1824. static inline void *reiserfs_node_data(const struct buffer_head *bh)
  1825. {
  1826. return bh->b_data + sizeof(struct block_head);
  1827. }
  1828. /* get key from internal node */
  1829. static inline struct reiserfs_key *internal_key(struct buffer_head *bh,
  1830. int item_num)
  1831. {
  1832. struct reiserfs_key *key = reiserfs_node_data(bh);
  1833. return &key[item_num];
  1834. }
  1835. /* get the item header from leaf node */
  1836. static inline struct item_head *item_head(const struct buffer_head *bh,
  1837. int item_num)
  1838. {
  1839. struct item_head *ih = reiserfs_node_data(bh);
  1840. return &ih[item_num];
  1841. }
  1842. /* get the key from leaf node */
  1843. static inline struct reiserfs_key *leaf_key(const struct buffer_head *bh,
  1844. int item_num)
  1845. {
  1846. return &item_head(bh, item_num)->ih_key;
  1847. }
  1848. static inline void *ih_item_body(const struct buffer_head *bh,
  1849. const struct item_head *ih)
  1850. {
  1851. return bh->b_data + ih_location(ih);
  1852. }
  1853. /* get item body from leaf node */
  1854. static inline void *item_body(const struct buffer_head *bh, int item_num)
  1855. {
  1856. return ih_item_body(bh, item_head(bh, item_num));
  1857. }
  1858. static inline struct item_head *tp_item_head(const struct treepath *path)
  1859. {
  1860. return item_head(PATH_PLAST_BUFFER(path), PATH_LAST_POSITION(path));
  1861. }
  1862. static inline void *tp_item_body(const struct treepath *path)
  1863. {
  1864. return item_body(PATH_PLAST_BUFFER(path), PATH_LAST_POSITION(path));
  1865. }
  1866. #define get_last_bh(path) PATH_PLAST_BUFFER(path)
  1867. #define get_item_pos(path) PATH_LAST_POSITION(path)
  1868. #define item_moved(ih,path) comp_items(ih, path)
  1869. #define path_changed(ih,path) comp_items (ih, path)
  1870. /* array of the entry headers */
  1871. /* get item body */
  1872. #define B_I_DEH(bh, ih) ((struct reiserfs_de_head *)(ih_item_body(bh, ih)))
  1873. /*
  1874. * length of the directory entry in directory item. This define
  1875. * calculates length of i-th directory entry using directory entry
  1876. * locations from dir entry head. When it calculates length of 0-th
  1877. * directory entry, it uses length of whole item in place of entry
  1878. * location of the non-existent following entry in the calculation.
  1879. * See picture above.
  1880. */
  1881. static inline int entry_length(const struct buffer_head *bh,
  1882. const struct item_head *ih, int pos_in_item)
  1883. {
  1884. struct reiserfs_de_head *deh;
  1885. deh = B_I_DEH(bh, ih) + pos_in_item;
  1886. if (pos_in_item)
  1887. return deh_location(deh - 1) - deh_location(deh);
  1888. return ih_item_len(ih) - deh_location(deh);
  1889. }
  1890. /***************************************************************************
  1891. * MISC *
  1892. ***************************************************************************/
  1893. /* Size of pointer to the unformatted node. */
  1894. #define UNFM_P_SIZE (sizeof(unp_t))
  1895. #define UNFM_P_SHIFT 2
  1896. /* in in-core inode key is stored on le form */
  1897. #define INODE_PKEY(inode) ((struct reiserfs_key *)(REISERFS_I(inode)->i_key))
  1898. #define MAX_UL_INT 0xffffffff
  1899. #define MAX_INT 0x7ffffff
  1900. #define MAX_US_INT 0xffff
  1901. // reiserfs version 2 has max offset 60 bits. Version 1 - 32 bit offset
  1902. static inline loff_t max_reiserfs_offset(struct inode *inode)
  1903. {
  1904. if (get_inode_item_key_version(inode) == KEY_FORMAT_3_5)
  1905. return (loff_t) U32_MAX;
  1906. return (loff_t) ((~(__u64) 0) >> 4);
  1907. }
  1908. #define MAX_KEY_OBJECTID MAX_UL_INT
  1909. #define MAX_B_NUM MAX_UL_INT
  1910. #define MAX_FC_NUM MAX_US_INT
  1911. /* the purpose is to detect overflow of an unsigned short */
  1912. #define REISERFS_LINK_MAX (MAX_US_INT - 1000)
  1913. /*
  1914. * The following defines are used in reiserfs_insert_item
  1915. * and reiserfs_append_item
  1916. */
  1917. #define REISERFS_KERNEL_MEM 0 /* kernel memory mode */
  1918. #define REISERFS_USER_MEM 1 /* user memory mode */
  1919. #define fs_generation(s) (REISERFS_SB(s)->s_generation_counter)
  1920. #define get_generation(s) atomic_read (&fs_generation(s))
  1921. #define FILESYSTEM_CHANGED_TB(tb) (get_generation((tb)->tb_sb) != (tb)->fs_gen)
  1922. #define __fs_changed(gen,s) (gen != get_generation (s))
  1923. #define fs_changed(gen,s) \
  1924. ({ \
  1925. reiserfs_cond_resched(s); \
  1926. __fs_changed(gen, s); \
  1927. })
  1928. /***************************************************************************
  1929. * FIXATE NODES *
  1930. ***************************************************************************/
  1931. #define VI_TYPE_LEFT_MERGEABLE 1
  1932. #define VI_TYPE_RIGHT_MERGEABLE 2
  1933. /*
  1934. * To make any changes in the tree we always first find node, that
  1935. * contains item to be changed/deleted or place to insert a new
  1936. * item. We call this node S. To do balancing we need to decide what
  1937. * we will shift to left/right neighbor, or to a new node, where new
  1938. * item will be etc. To make this analysis simpler we build virtual
  1939. * node. Virtual node is an array of items, that will replace items of
  1940. * node S. (For instance if we are going to delete an item, virtual
  1941. * node does not contain it). Virtual node keeps information about
  1942. * item sizes and types, mergeability of first and last items, sizes
  1943. * of all entries in directory item. We use this array of items when
  1944. * calculating what we can shift to neighbors and how many nodes we
  1945. * have to have if we do not any shiftings, if we shift to left/right
  1946. * neighbor or to both.
  1947. */
  1948. struct virtual_item {
  1949. int vi_index; /* index in the array of item operations */
  1950. unsigned short vi_type; /* left/right mergeability */
  1951. /* length of item that it will have after balancing */
  1952. unsigned short vi_item_len;
  1953. struct item_head *vi_ih;
  1954. const char *vi_item; /* body of item (old or new) */
  1955. const void *vi_new_data; /* 0 always but paste mode */
  1956. void *vi_uarea; /* item specific area */
  1957. };
  1958. struct virtual_node {
  1959. /* this is a pointer to the free space in the buffer */
  1960. char *vn_free_ptr;
  1961. unsigned short vn_nr_item; /* number of items in virtual node */
  1962. /*
  1963. * size of node , that node would have if it has
  1964. * unlimited size and no balancing is performed
  1965. */
  1966. short vn_size;
  1967. /* mode of balancing (paste, insert, delete, cut) */
  1968. short vn_mode;
  1969. short vn_affected_item_num;
  1970. short vn_pos_in_item;
  1971. /* item header of inserted item, 0 for other modes */
  1972. struct item_head *vn_ins_ih;
  1973. const void *vn_data;
  1974. /* array of items (including a new one, excluding item to be deleted) */
  1975. struct virtual_item *vn_vi;
  1976. };
  1977. /* used by directory items when creating virtual nodes */
  1978. struct direntry_uarea {
  1979. int flags;
  1980. __u16 entry_count;
  1981. __u16 entry_sizes[1];
  1982. } __attribute__ ((__packed__));
  1983. /***************************************************************************
  1984. * TREE BALANCE *
  1985. ***************************************************************************/
  1986. /*
  1987. * This temporary structure is used in tree balance algorithms, and
  1988. * constructed as we go to the extent that its various parts are
  1989. * needed. It contains arrays of nodes that can potentially be
  1990. * involved in the balancing of node S, and parameters that define how
  1991. * each of the nodes must be balanced. Note that in these algorithms
  1992. * for balancing the worst case is to need to balance the current node
  1993. * S and the left and right neighbors and all of their parents plus
  1994. * create a new node. We implement S1 balancing for the leaf nodes
  1995. * and S0 balancing for the internal nodes (S1 and S0 are defined in
  1996. * our papers.)
  1997. */
  1998. /* size of the array of buffers to free at end of do_balance */
  1999. #define MAX_FREE_BLOCK 7
  2000. /* maximum number of FEB blocknrs on a single level */
  2001. #define MAX_AMOUNT_NEEDED 2
  2002. /* someday somebody will prefix every field in this struct with tb_ */
  2003. struct tree_balance {
  2004. int tb_mode;
  2005. int need_balance_dirty;
  2006. struct super_block *tb_sb;
  2007. struct reiserfs_transaction_handle *transaction_handle;
  2008. struct treepath *tb_path;
  2009. /* array of left neighbors of nodes in the path */
  2010. struct buffer_head *L[MAX_HEIGHT];
  2011. /* array of right neighbors of nodes in the path */
  2012. struct buffer_head *R[MAX_HEIGHT];
  2013. /* array of fathers of the left neighbors */
  2014. struct buffer_head *FL[MAX_HEIGHT];
  2015. /* array of fathers of the right neighbors */
  2016. struct buffer_head *FR[MAX_HEIGHT];
  2017. /* array of common parents of center node and its left neighbor */
  2018. struct buffer_head *CFL[MAX_HEIGHT];
  2019. /* array of common parents of center node and its right neighbor */
  2020. struct buffer_head *CFR[MAX_HEIGHT];
  2021. /*
  2022. * array of empty buffers. Number of buffers in array equals
  2023. * cur_blknum.
  2024. */
  2025. struct buffer_head *FEB[MAX_FEB_SIZE];
  2026. struct buffer_head *used[MAX_FEB_SIZE];
  2027. struct buffer_head *thrown[MAX_FEB_SIZE];
  2028. /*
  2029. * array of number of items which must be shifted to the left in
  2030. * order to balance the current node; for leaves includes item that
  2031. * will be partially shifted; for internal nodes, it is the number
  2032. * of child pointers rather than items. It includes the new item
  2033. * being created. The code sometimes subtracts one to get the
  2034. * number of wholly shifted items for other purposes.
  2035. */
  2036. int lnum[MAX_HEIGHT];
  2037. /* substitute right for left in comment above */
  2038. int rnum[MAX_HEIGHT];
  2039. /*
  2040. * array indexed by height h mapping the key delimiting L[h] and
  2041. * S[h] to its item number within the node CFL[h]
  2042. */
  2043. int lkey[MAX_HEIGHT];
  2044. /* substitute r for l in comment above */
  2045. int rkey[MAX_HEIGHT];
  2046. /*
  2047. * the number of bytes by we are trying to add or remove from
  2048. * S[h]. A negative value means removing.
  2049. */
  2050. int insert_size[MAX_HEIGHT];
  2051. /*
  2052. * number of nodes that will replace node S[h] after balancing
  2053. * on the level h of the tree. If 0 then S is being deleted,
  2054. * if 1 then S is remaining and no new nodes are being created,
  2055. * if 2 or 3 then 1 or 2 new nodes is being created
  2056. */
  2057. int blknum[MAX_HEIGHT];
  2058. /* fields that are used only for balancing leaves of the tree */
  2059. /* number of empty blocks having been already allocated */
  2060. int cur_blknum;
  2061. /* number of items that fall into left most node when S[0] splits */
  2062. int s0num;
  2063. /*
  2064. * number of bytes which can flow to the left neighbor from the left
  2065. * most liquid item that cannot be shifted from S[0] entirely
  2066. * if -1 then nothing will be partially shifted
  2067. */
  2068. int lbytes;
  2069. /*
  2070. * number of bytes which will flow to the right neighbor from the right
  2071. * most liquid item that cannot be shifted from S[0] entirely
  2072. * if -1 then nothing will be partially shifted
  2073. */
  2074. int rbytes;
  2075. /*
  2076. * index into the array of item headers in
  2077. * S[0] of the affected item
  2078. */
  2079. int item_pos;
  2080. /* new nodes allocated to hold what could not fit into S */
  2081. struct buffer_head *S_new[2];
  2082. /*
  2083. * number of items that will be placed into nodes in S_new
  2084. * when S[0] splits
  2085. */
  2086. int snum[2];
  2087. /*
  2088. * number of bytes which flow to nodes in S_new when S[0] splits
  2089. * note: if S[0] splits into 3 nodes, then items do not need to be cut
  2090. */
  2091. int sbytes[2];
  2092. int pos_in_item;
  2093. int zeroes_num;
  2094. /*
  2095. * buffers which are to be freed after do_balance finishes
  2096. * by unfix_nodes
  2097. */
  2098. struct buffer_head *buf_to_free[MAX_FREE_BLOCK];
  2099. /*
  2100. * kmalloced memory. Used to create virtual node and keep
  2101. * map of dirtied bitmap blocks
  2102. */
  2103. char *vn_buf;
  2104. int vn_buf_size; /* size of the vn_buf */
  2105. /* VN starts after bitmap of bitmap blocks */
  2106. struct virtual_node *tb_vn;
  2107. /*
  2108. * saved value of `reiserfs_generation' counter see
  2109. * FILESYSTEM_CHANGED() macro in reiserfs_fs.h
  2110. */
  2111. int fs_gen;
  2112. #ifdef DISPLACE_NEW_PACKING_LOCALITIES
  2113. /*
  2114. * key pointer, to pass to block allocator or
  2115. * another low-level subsystem
  2116. */
  2117. struct in_core_key key;
  2118. #endif
  2119. };
  2120. /* These are modes of balancing */
  2121. /* When inserting an item. */
  2122. #define M_INSERT 'i'
  2123. /*
  2124. * When inserting into (directories only) or appending onto an already
  2125. * existent item.
  2126. */
  2127. #define M_PASTE 'p'
  2128. /* When deleting an item. */
  2129. #define M_DELETE 'd'
  2130. /* When truncating an item or removing an entry from a (directory) item. */
  2131. #define M_CUT 'c'
  2132. /* used when balancing on leaf level skipped (in reiserfsck) */
  2133. #define M_INTERNAL 'n'
  2134. /*
  2135. * When further balancing is not needed, then do_balance does not need
  2136. * to be called.
  2137. */
  2138. #define M_SKIP_BALANCING 's'
  2139. #define M_CONVERT 'v'
  2140. /* modes of leaf_move_items */
  2141. #define LEAF_FROM_S_TO_L 0
  2142. #define LEAF_FROM_S_TO_R 1
  2143. #define LEAF_FROM_R_TO_L 2
  2144. #define LEAF_FROM_L_TO_R 3
  2145. #define LEAF_FROM_S_TO_SNEW 4
  2146. #define FIRST_TO_LAST 0
  2147. #define LAST_TO_FIRST 1
  2148. /*
  2149. * used in do_balance for passing parent of node information that has
  2150. * been gotten from tb struct
  2151. */
  2152. struct buffer_info {
  2153. struct tree_balance *tb;
  2154. struct buffer_head *bi_bh;
  2155. struct buffer_head *bi_parent;
  2156. int bi_position;
  2157. };
  2158. static inline struct super_block *sb_from_tb(struct tree_balance *tb)
  2159. {
  2160. return tb ? tb->tb_sb : NULL;
  2161. }
  2162. static inline struct super_block *sb_from_bi(struct buffer_info *bi)
  2163. {
  2164. return bi ? sb_from_tb(bi->tb) : NULL;
  2165. }
  2166. /*
  2167. * there are 4 types of items: stat data, directory item, indirect, direct.
  2168. * +-------------------+------------+--------------+------------+
  2169. * | | k_offset | k_uniqueness | mergeable? |
  2170. * +-------------------+------------+--------------+------------+
  2171. * | stat data | 0 | 0 | no |
  2172. * +-------------------+------------+--------------+------------+
  2173. * | 1st directory item| DOT_OFFSET | DIRENTRY_ .. | no |
  2174. * | non 1st directory | hash value | UNIQUENESS | yes |
  2175. * | item | | | |
  2176. * +-------------------+------------+--------------+------------+
  2177. * | indirect item | offset + 1 |TYPE_INDIRECT | [1] |
  2178. * +-------------------+------------+--------------+------------+
  2179. * | direct item | offset + 1 |TYPE_DIRECT | [2] |
  2180. * +-------------------+------------+--------------+------------+
  2181. *
  2182. * [1] if this is not the first indirect item of the object
  2183. * [2] if this is not the first direct item of the object
  2184. */
  2185. struct item_operations {
  2186. int (*bytes_number) (struct item_head * ih, int block_size);
  2187. void (*decrement_key) (struct cpu_key *);
  2188. int (*is_left_mergeable) (struct reiserfs_key * ih,
  2189. unsigned long bsize);
  2190. void (*print_item) (struct item_head *, char *item);
  2191. void (*check_item) (struct item_head *, char *item);
  2192. int (*create_vi) (struct virtual_node * vn, struct virtual_item * vi,
  2193. int is_affected, int insert_size);
  2194. int (*check_left) (struct virtual_item * vi, int free,
  2195. int start_skip, int end_skip);
  2196. int (*check_right) (struct virtual_item * vi, int free);
  2197. int (*part_size) (struct virtual_item * vi, int from, int to);
  2198. int (*unit_num) (struct virtual_item * vi);
  2199. void (*print_vi) (struct virtual_item * vi);
  2200. };
  2201. extern struct item_operations *item_ops[TYPE_ANY + 1];
  2202. #define op_bytes_number(ih,bsize) item_ops[le_ih_k_type (ih)]->bytes_number (ih, bsize)
  2203. #define op_is_left_mergeable(key,bsize) item_ops[le_key_k_type (le_key_version (key), key)]->is_left_mergeable (key, bsize)
  2204. #define op_print_item(ih,item) item_ops[le_ih_k_type (ih)]->print_item (ih, item)
  2205. #define op_check_item(ih,item) item_ops[le_ih_k_type (ih)]->check_item (ih, item)
  2206. #define op_create_vi(vn,vi,is_affected,insert_size) item_ops[le_ih_k_type ((vi)->vi_ih)]->create_vi (vn,vi,is_affected,insert_size)
  2207. #define op_check_left(vi,free,start_skip,end_skip) item_ops[(vi)->vi_index]->check_left (vi, free, start_skip, end_skip)
  2208. #define op_check_right(vi,free) item_ops[(vi)->vi_index]->check_right (vi, free)
  2209. #define op_part_size(vi,from,to) item_ops[(vi)->vi_index]->part_size (vi, from, to)
  2210. #define op_unit_num(vi) item_ops[(vi)->vi_index]->unit_num (vi)
  2211. #define op_print_vi(vi) item_ops[(vi)->vi_index]->print_vi (vi)
  2212. #define COMP_SHORT_KEYS comp_short_keys
  2213. /* number of blocks pointed to by the indirect item */
  2214. #define I_UNFM_NUM(ih) (ih_item_len(ih) / UNFM_P_SIZE)
  2215. /*
  2216. * the used space within the unformatted node corresponding
  2217. * to pos within the item pointed to by ih
  2218. */
  2219. #define I_POS_UNFM_SIZE(ih,pos,size) (((pos) == I_UNFM_NUM(ih) - 1 ) ? (size) - ih_free_space(ih) : (size))
  2220. /*
  2221. * number of bytes contained by the direct item or the
  2222. * unformatted nodes the indirect item points to
  2223. */
  2224. /* following defines use reiserfs buffer header and item header */
  2225. /* get stat-data */
  2226. #define B_I_STAT_DATA(bh, ih) ( (struct stat_data * )((bh)->b_data + ih_location(ih)) )
  2227. /* this is 3976 for size==4096 */
  2228. #define MAX_DIRECT_ITEM_LEN(size) ((size) - BLKH_SIZE - 2*IH_SIZE - SD_SIZE - UNFM_P_SIZE)
  2229. /*
  2230. * indirect items consist of entries which contain blocknrs, pos
  2231. * indicates which entry, and B_I_POS_UNFM_POINTER resolves to the
  2232. * blocknr contained by the entry pos points to
  2233. */
  2234. #define B_I_POS_UNFM_POINTER(bh, ih, pos) \
  2235. le32_to_cpu(*(((unp_t *)ih_item_body(bh, ih)) + (pos)))
  2236. #define PUT_B_I_POS_UNFM_POINTER(bh, ih, pos, val) \
  2237. (*(((unp_t *)ih_item_body(bh, ih)) + (pos)) = cpu_to_le32(val))
  2238. struct reiserfs_iget_args {
  2239. __u32 objectid;
  2240. __u32 dirid;
  2241. };
  2242. /***************************************************************************
  2243. * FUNCTION DECLARATIONS *
  2244. ***************************************************************************/
  2245. #define get_journal_desc_magic(bh) (bh->b_data + bh->b_size - 12)
  2246. #define journal_trans_half(blocksize) \
  2247. ((blocksize - sizeof (struct reiserfs_journal_desc) + sizeof (__u32) - 12) / sizeof (__u32))
  2248. /* journal.c see journal.c for all the comments here */
  2249. /* first block written in a commit. */
  2250. struct reiserfs_journal_desc {
  2251. __le32 j_trans_id; /* id of commit */
  2252. /* length of commit. len +1 is the commit block */
  2253. __le32 j_len;
  2254. __le32 j_mount_id; /* mount id of this trans */
  2255. __le32 j_realblock[1]; /* real locations for each block */
  2256. };
  2257. #define get_desc_trans_id(d) le32_to_cpu((d)->j_trans_id)
  2258. #define get_desc_trans_len(d) le32_to_cpu((d)->j_len)
  2259. #define get_desc_mount_id(d) le32_to_cpu((d)->j_mount_id)
  2260. #define set_desc_trans_id(d,val) do { (d)->j_trans_id = cpu_to_le32 (val); } while (0)
  2261. #define set_desc_trans_len(d,val) do { (d)->j_len = cpu_to_le32 (val); } while (0)
  2262. #define set_desc_mount_id(d,val) do { (d)->j_mount_id = cpu_to_le32 (val); } while (0)
  2263. /* last block written in a commit */
  2264. struct reiserfs_journal_commit {
  2265. __le32 j_trans_id; /* must match j_trans_id from the desc block */
  2266. __le32 j_len; /* ditto */
  2267. __le32 j_realblock[1]; /* real locations for each block */
  2268. };
  2269. #define get_commit_trans_id(c) le32_to_cpu((c)->j_trans_id)
  2270. #define get_commit_trans_len(c) le32_to_cpu((c)->j_len)
  2271. #define get_commit_mount_id(c) le32_to_cpu((c)->j_mount_id)
  2272. #define set_commit_trans_id(c,val) do { (c)->j_trans_id = cpu_to_le32 (val); } while (0)
  2273. #define set_commit_trans_len(c,val) do { (c)->j_len = cpu_to_le32 (val); } while (0)
  2274. /*
  2275. * this header block gets written whenever a transaction is considered
  2276. * fully flushed, and is more recent than the last fully flushed transaction.
  2277. * fully flushed means all the log blocks and all the real blocks are on
  2278. * disk, and this transaction does not need to be replayed.
  2279. */
  2280. struct reiserfs_journal_header {
  2281. /* id of last fully flushed transaction */
  2282. __le32 j_last_flush_trans_id;
  2283. /* offset in the log of where to start replay after a crash */
  2284. __le32 j_first_unflushed_offset;
  2285. __le32 j_mount_id;
  2286. /* 12 */ struct journal_params jh_journal;
  2287. };
  2288. /* biggest tunable defines are right here */
  2289. #define JOURNAL_BLOCK_COUNT 8192 /* number of blocks in the journal */
  2290. /* biggest possible single transaction, don't change for now (8/3/99) */
  2291. #define JOURNAL_TRANS_MAX_DEFAULT 1024
  2292. #define JOURNAL_TRANS_MIN_DEFAULT 256
  2293. /*
  2294. * max blocks to batch into one transaction,
  2295. * don't make this any bigger than 900
  2296. */
  2297. #define JOURNAL_MAX_BATCH_DEFAULT 900
  2298. #define JOURNAL_MIN_RATIO 2
  2299. #define JOURNAL_MAX_COMMIT_AGE 30
  2300. #define JOURNAL_MAX_TRANS_AGE 30
  2301. #define JOURNAL_PER_BALANCE_CNT (3 * (MAX_HEIGHT-2) + 9)
  2302. #define JOURNAL_BLOCKS_PER_OBJECT(sb) (JOURNAL_PER_BALANCE_CNT * 3 + \
  2303. 2 * (REISERFS_QUOTA_INIT_BLOCKS(sb) + \
  2304. REISERFS_QUOTA_TRANS_BLOCKS(sb)))
  2305. #ifdef CONFIG_QUOTA
  2306. #define REISERFS_QUOTA_OPTS ((1 << REISERFS_USRQUOTA) | (1 << REISERFS_GRPQUOTA))
  2307. /* We need to update data and inode (atime) */
  2308. #define REISERFS_QUOTA_TRANS_BLOCKS(s) (REISERFS_SB(s)->s_mount_opt & REISERFS_QUOTA_OPTS ? 2 : 0)
  2309. /* 1 balancing, 1 bitmap, 1 data per write + stat data update */
  2310. #define REISERFS_QUOTA_INIT_BLOCKS(s) (REISERFS_SB(s)->s_mount_opt & REISERFS_QUOTA_OPTS ? \
  2311. (DQUOT_INIT_ALLOC*(JOURNAL_PER_BALANCE_CNT+2)+DQUOT_INIT_REWRITE+1) : 0)
  2312. /* same as with INIT */
  2313. #define REISERFS_QUOTA_DEL_BLOCKS(s) (REISERFS_SB(s)->s_mount_opt & REISERFS_QUOTA_OPTS ? \
  2314. (DQUOT_DEL_ALLOC*(JOURNAL_PER_BALANCE_CNT+2)+DQUOT_DEL_REWRITE+1) : 0)
  2315. #else
  2316. #define REISERFS_QUOTA_TRANS_BLOCKS(s) 0
  2317. #define REISERFS_QUOTA_INIT_BLOCKS(s) 0
  2318. #define REISERFS_QUOTA_DEL_BLOCKS(s) 0
  2319. #endif
  2320. /*
  2321. * both of these can be as low as 1, or as high as you want. The min is the
  2322. * number of 4k bitmap nodes preallocated on mount. New nodes are allocated
  2323. * as needed, and released when transactions are committed. On release, if
  2324. * the current number of nodes is > max, the node is freed, otherwise,
  2325. * it is put on a free list for faster use later.
  2326. */
  2327. #define REISERFS_MIN_BITMAP_NODES 10
  2328. #define REISERFS_MAX_BITMAP_NODES 100
  2329. /* these are based on journal hash size of 8192 */
  2330. #define JBH_HASH_SHIFT 13
  2331. #define JBH_HASH_MASK 8191
  2332. #define _jhashfn(sb,block) \
  2333. (((unsigned long)sb>>L1_CACHE_SHIFT) ^ \
  2334. (((block)<<(JBH_HASH_SHIFT - 6)) ^ ((block) >> 13) ^ ((block) << (JBH_HASH_SHIFT - 12))))
  2335. #define journal_hash(t,sb,block) ((t)[_jhashfn((sb),(block)) & JBH_HASH_MASK])
  2336. /* We need these to make journal.c code more readable */
  2337. #define journal_find_get_block(s, block) __find_get_block(SB_JOURNAL(s)->j_dev_bd, block, s->s_blocksize)
  2338. #define journal_getblk(s, block) __getblk(SB_JOURNAL(s)->j_dev_bd, block, s->s_blocksize)
  2339. #define journal_bread(s, block) __bread(SB_JOURNAL(s)->j_dev_bd, block, s->s_blocksize)
  2340. enum reiserfs_bh_state_bits {
  2341. BH_JDirty = BH_PrivateStart, /* buffer is in current transaction */
  2342. BH_JDirty_wait,
  2343. /*
  2344. * disk block was taken off free list before being in a
  2345. * finished transaction, or written to disk. Can be reused immed.
  2346. */
  2347. BH_JNew,
  2348. BH_JPrepared,
  2349. BH_JRestore_dirty,
  2350. BH_JTest, /* debugging only will go away */
  2351. };
  2352. BUFFER_FNS(JDirty, journaled);
  2353. TAS_BUFFER_FNS(JDirty, journaled);
  2354. BUFFER_FNS(JDirty_wait, journal_dirty);
  2355. TAS_BUFFER_FNS(JDirty_wait, journal_dirty);
  2356. BUFFER_FNS(JNew, journal_new);
  2357. TAS_BUFFER_FNS(JNew, journal_new);
  2358. BUFFER_FNS(JPrepared, journal_prepared);
  2359. TAS_BUFFER_FNS(JPrepared, journal_prepared);
  2360. BUFFER_FNS(JRestore_dirty, journal_restore_dirty);
  2361. TAS_BUFFER_FNS(JRestore_dirty, journal_restore_dirty);
  2362. BUFFER_FNS(JTest, journal_test);
  2363. TAS_BUFFER_FNS(JTest, journal_test);
  2364. /* transaction handle which is passed around for all journal calls */
  2365. struct reiserfs_transaction_handle {
  2366. /*
  2367. * super for this FS when journal_begin was called. saves calls to
  2368. * reiserfs_get_super also used by nested transactions to make
  2369. * sure they are nesting on the right FS _must_ be first
  2370. * in the handle
  2371. */
  2372. struct super_block *t_super;
  2373. int t_refcount;
  2374. int t_blocks_logged; /* number of blocks this writer has logged */
  2375. int t_blocks_allocated; /* number of blocks this writer allocated */
  2376. /* sanity check, equals the current trans id */
  2377. unsigned int t_trans_id;
  2378. void *t_handle_save; /* save existing current->journal_info */
  2379. /*
  2380. * if new block allocation occurres, that block
  2381. * should be displaced from others
  2382. */
  2383. unsigned displace_new_blocks:1;
  2384. struct list_head t_list;
  2385. };
  2386. /*
  2387. * used to keep track of ordered and tail writes, attached to the buffer
  2388. * head through b_journal_head.
  2389. */
  2390. struct reiserfs_jh {
  2391. struct reiserfs_journal_list *jl;
  2392. struct buffer_head *bh;
  2393. struct list_head list;
  2394. };
  2395. void reiserfs_free_jh(struct buffer_head *bh);
  2396. int reiserfs_add_tail_list(struct inode *inode, struct buffer_head *bh);
  2397. int reiserfs_add_ordered_list(struct inode *inode, struct buffer_head *bh);
  2398. int journal_mark_dirty(struct reiserfs_transaction_handle *,
  2399. struct buffer_head *bh);
  2400. static inline int reiserfs_file_data_log(struct inode *inode)
  2401. {
  2402. if (reiserfs_data_log(inode->i_sb) ||
  2403. (REISERFS_I(inode)->i_flags & i_data_log))
  2404. return 1;
  2405. return 0;
  2406. }
  2407. static inline int reiserfs_transaction_running(struct super_block *s)
  2408. {
  2409. struct reiserfs_transaction_handle *th = current->journal_info;
  2410. if (th && th->t_super == s)
  2411. return 1;
  2412. if (th && th->t_super == NULL)
  2413. BUG();
  2414. return 0;
  2415. }
  2416. static inline int reiserfs_transaction_free_space(struct reiserfs_transaction_handle *th)
  2417. {
  2418. return th->t_blocks_allocated - th->t_blocks_logged;
  2419. }
  2420. struct reiserfs_transaction_handle *reiserfs_persistent_transaction(struct
  2421. super_block
  2422. *,
  2423. int count);
  2424. int reiserfs_end_persistent_transaction(struct reiserfs_transaction_handle *);
  2425. void reiserfs_vfs_truncate_file(struct inode *inode);
  2426. int reiserfs_commit_page(struct inode *inode, struct page *page,
  2427. unsigned from, unsigned to);
  2428. void reiserfs_flush_old_commits(struct super_block *);
  2429. int reiserfs_commit_for_inode(struct inode *);
  2430. int reiserfs_inode_needs_commit(struct inode *);
  2431. void reiserfs_update_inode_transaction(struct inode *);
  2432. void reiserfs_wait_on_write_block(struct super_block *s);
  2433. void reiserfs_block_writes(struct reiserfs_transaction_handle *th);
  2434. void reiserfs_allow_writes(struct super_block *s);
  2435. void reiserfs_check_lock_depth(struct super_block *s, char *caller);
  2436. int reiserfs_prepare_for_journal(struct super_block *, struct buffer_head *bh,
  2437. int wait);
  2438. void reiserfs_restore_prepared_buffer(struct super_block *,
  2439. struct buffer_head *bh);
  2440. int journal_init(struct super_block *, const char *j_dev_name, int old_format,
  2441. unsigned int);
  2442. int journal_release(struct reiserfs_transaction_handle *, struct super_block *);
  2443. int journal_release_error(struct reiserfs_transaction_handle *,
  2444. struct super_block *);
  2445. int journal_end(struct reiserfs_transaction_handle *);
  2446. int journal_end_sync(struct reiserfs_transaction_handle *);
  2447. int journal_mark_freed(struct reiserfs_transaction_handle *,
  2448. struct super_block *, b_blocknr_t blocknr);
  2449. int journal_transaction_should_end(struct reiserfs_transaction_handle *, int);
  2450. int reiserfs_in_journal(struct super_block *sb, unsigned int bmap_nr,
  2451. int bit_nr, int searchall, b_blocknr_t *next);
  2452. int journal_begin(struct reiserfs_transaction_handle *,
  2453. struct super_block *sb, unsigned long);
  2454. int journal_join_abort(struct reiserfs_transaction_handle *,
  2455. struct super_block *sb);
  2456. void reiserfs_abort_journal(struct super_block *sb, int errno);
  2457. void reiserfs_abort(struct super_block *sb, int errno, const char *fmt, ...);
  2458. int reiserfs_allocate_list_bitmaps(struct super_block *s,
  2459. struct reiserfs_list_bitmap *, unsigned int);
  2460. void reiserfs_schedule_old_flush(struct super_block *s);
  2461. void add_save_link(struct reiserfs_transaction_handle *th,
  2462. struct inode *inode, int truncate);
  2463. int remove_save_link(struct inode *inode, int truncate);
  2464. /* objectid.c */
  2465. __u32 reiserfs_get_unused_objectid(struct reiserfs_transaction_handle *th);
  2466. void reiserfs_release_objectid(struct reiserfs_transaction_handle *th,
  2467. __u32 objectid_to_release);
  2468. int reiserfs_convert_objectid_map_v1(struct super_block *);
  2469. /* stree.c */
  2470. int B_IS_IN_TREE(const struct buffer_head *);
  2471. extern void copy_item_head(struct item_head *to,
  2472. const struct item_head *from);
  2473. /* first key is in cpu form, second - le */
  2474. extern int comp_short_keys(const struct reiserfs_key *le_key,
  2475. const struct cpu_key *cpu_key);
  2476. extern void le_key2cpu_key(struct cpu_key *to, const struct reiserfs_key *from);
  2477. /* both are in le form */
  2478. extern int comp_le_keys(const struct reiserfs_key *,
  2479. const struct reiserfs_key *);
  2480. extern int comp_short_le_keys(const struct reiserfs_key *,
  2481. const struct reiserfs_key *);
  2482. /* * get key version from on disk key - kludge */
  2483. static inline int le_key_version(const struct reiserfs_key *key)
  2484. {
  2485. int type;
  2486. type = offset_v2_k_type(&(key->u.k_offset_v2));
  2487. if (type != TYPE_DIRECT && type != TYPE_INDIRECT
  2488. && type != TYPE_DIRENTRY)
  2489. return KEY_FORMAT_3_5;
  2490. return KEY_FORMAT_3_6;
  2491. }
  2492. static inline void copy_key(struct reiserfs_key *to,
  2493. const struct reiserfs_key *from)
  2494. {
  2495. memcpy(to, from, KEY_SIZE);
  2496. }
  2497. int comp_items(const struct item_head *stored_ih, const struct treepath *path);
  2498. const struct reiserfs_key *get_rkey(const struct treepath *chk_path,
  2499. const struct super_block *sb);
  2500. int search_by_key(struct super_block *, const struct cpu_key *,
  2501. struct treepath *, int);
  2502. #define search_item(s,key,path) search_by_key (s, key, path, DISK_LEAF_NODE_LEVEL)
  2503. int search_for_position_by_key(struct super_block *sb,
  2504. const struct cpu_key *cpu_key,
  2505. struct treepath *search_path);
  2506. extern void decrement_bcount(struct buffer_head *bh);
  2507. void decrement_counters_in_path(struct treepath *search_path);
  2508. void pathrelse(struct treepath *search_path);
  2509. int reiserfs_check_path(struct treepath *p);
  2510. void pathrelse_and_restore(struct super_block *s, struct treepath *search_path);
  2511. int reiserfs_insert_item(struct reiserfs_transaction_handle *th,
  2512. struct treepath *path,
  2513. const struct cpu_key *key,
  2514. struct item_head *ih,
  2515. struct inode *inode, const char *body);
  2516. int reiserfs_paste_into_item(struct reiserfs_transaction_handle *th,
  2517. struct treepath *path,
  2518. const struct cpu_key *key,
  2519. struct inode *inode,
  2520. const char *body, int paste_size);
  2521. int reiserfs_cut_from_item(struct reiserfs_transaction_handle *th,
  2522. struct treepath *path,
  2523. struct cpu_key *key,
  2524. struct inode *inode,
  2525. struct page *page, loff_t new_file_size);
  2526. int reiserfs_delete_item(struct reiserfs_transaction_handle *th,
  2527. struct treepath *path,
  2528. const struct cpu_key *key,
  2529. struct inode *inode, struct buffer_head *un_bh);
  2530. void reiserfs_delete_solid_item(struct reiserfs_transaction_handle *th,
  2531. struct inode *inode, struct reiserfs_key *key);
  2532. int reiserfs_delete_object(struct reiserfs_transaction_handle *th,
  2533. struct inode *inode);
  2534. int reiserfs_do_truncate(struct reiserfs_transaction_handle *th,
  2535. struct inode *inode, struct page *,
  2536. int update_timestamps);
  2537. #define i_block_size(inode) ((inode)->i_sb->s_blocksize)
  2538. #define file_size(inode) ((inode)->i_size)
  2539. #define tail_size(inode) (file_size (inode) & (i_block_size (inode) - 1))
  2540. #define tail_has_to_be_packed(inode) (have_large_tails ((inode)->i_sb)?\
  2541. !STORE_TAIL_IN_UNFM_S1(file_size (inode), tail_size(inode), inode->i_sb->s_blocksize):have_small_tails ((inode)->i_sb)?!STORE_TAIL_IN_UNFM_S2(file_size (inode), tail_size(inode), inode->i_sb->s_blocksize):0 )
  2542. void padd_item(char *item, int total_length, int length);
  2543. /* inode.c */
  2544. /* args for the create parameter of reiserfs_get_block */
  2545. #define GET_BLOCK_NO_CREATE 0 /* don't create new blocks or convert tails */
  2546. #define GET_BLOCK_CREATE 1 /* add anything you need to find block */
  2547. #define GET_BLOCK_NO_HOLE 2 /* return -ENOENT for file holes */
  2548. #define GET_BLOCK_READ_DIRECT 4 /* read the tail if indirect item not found */
  2549. #define GET_BLOCK_NO_IMUX 8 /* i_mutex is not held, don't preallocate */
  2550. #define GET_BLOCK_NO_DANGLE 16 /* don't leave any transactions running */
  2551. void reiserfs_read_locked_inode(struct inode *inode,
  2552. struct reiserfs_iget_args *args);
  2553. int reiserfs_find_actor(struct inode *inode, void *p);
  2554. int reiserfs_init_locked_inode(struct inode *inode, void *p);
  2555. void reiserfs_evict_inode(struct inode *inode);
  2556. int reiserfs_write_inode(struct inode *inode, struct writeback_control *wbc);
  2557. int reiserfs_get_block(struct inode *inode, sector_t block,
  2558. struct buffer_head *bh_result, int create);
  2559. struct dentry *reiserfs_fh_to_dentry(struct super_block *sb, struct fid *fid,
  2560. int fh_len, int fh_type);
  2561. struct dentry *reiserfs_fh_to_parent(struct super_block *sb, struct fid *fid,
  2562. int fh_len, int fh_type);
  2563. int reiserfs_encode_fh(struct inode *inode, __u32 * data, int *lenp,
  2564. struct inode *parent);
  2565. int reiserfs_truncate_file(struct inode *, int update_timestamps);
  2566. void make_cpu_key(struct cpu_key *cpu_key, struct inode *inode, loff_t offset,
  2567. int type, int key_length);
  2568. void make_le_item_head(struct item_head *ih, const struct cpu_key *key,
  2569. int version,
  2570. loff_t offset, int type, int length, int entry_count);
  2571. struct inode *reiserfs_iget(struct super_block *s, const struct cpu_key *key);
  2572. struct reiserfs_security_handle;
  2573. int reiserfs_new_inode(struct reiserfs_transaction_handle *th,
  2574. struct inode *dir, umode_t mode,
  2575. const char *symname, loff_t i_size,
  2576. struct dentry *dentry, struct inode *inode,
  2577. struct reiserfs_security_handle *security);
  2578. void reiserfs_update_sd_size(struct reiserfs_transaction_handle *th,
  2579. struct inode *inode, loff_t size);
  2580. static inline void reiserfs_update_sd(struct reiserfs_transaction_handle *th,
  2581. struct inode *inode)
  2582. {
  2583. reiserfs_update_sd_size(th, inode, inode->i_size);
  2584. }
  2585. void sd_attrs_to_i_attrs(__u16 sd_attrs, struct inode *inode);
  2586. void i_attrs_to_sd_attrs(struct inode *inode, __u16 * sd_attrs);
  2587. int reiserfs_setattr(struct dentry *dentry, struct iattr *attr);
  2588. int __reiserfs_write_begin(struct page *page, unsigned from, unsigned len);
  2589. /* namei.c */
  2590. void set_de_name_and_namelen(struct reiserfs_dir_entry *de);
  2591. int search_by_entry_key(struct super_block *sb, const struct cpu_key *key,
  2592. struct treepath *path, struct reiserfs_dir_entry *de);
  2593. struct dentry *reiserfs_get_parent(struct dentry *);
  2594. #ifdef CONFIG_REISERFS_PROC_INFO
  2595. int reiserfs_proc_info_init(struct super_block *sb);
  2596. int reiserfs_proc_info_done(struct super_block *sb);
  2597. int reiserfs_proc_info_global_init(void);
  2598. int reiserfs_proc_info_global_done(void);
  2599. #define PROC_EXP( e ) e
  2600. #define __PINFO( sb ) REISERFS_SB(sb) -> s_proc_info_data
  2601. #define PROC_INFO_MAX( sb, field, value ) \
  2602. __PINFO( sb ).field = \
  2603. max( REISERFS_SB( sb ) -> s_proc_info_data.field, value )
  2604. #define PROC_INFO_INC( sb, field ) ( ++ ( __PINFO( sb ).field ) )
  2605. #define PROC_INFO_ADD( sb, field, val ) ( __PINFO( sb ).field += ( val ) )
  2606. #define PROC_INFO_BH_STAT( sb, bh, level ) \
  2607. PROC_INFO_INC( sb, sbk_read_at[ ( level ) ] ); \
  2608. PROC_INFO_ADD( sb, free_at[ ( level ) ], B_FREE_SPACE( bh ) ); \
  2609. PROC_INFO_ADD( sb, items_at[ ( level ) ], B_NR_ITEMS( bh ) )
  2610. #else
  2611. static inline int reiserfs_proc_info_init(struct super_block *sb)
  2612. {
  2613. return 0;
  2614. }
  2615. static inline int reiserfs_proc_info_done(struct super_block *sb)
  2616. {
  2617. return 0;
  2618. }
  2619. static inline int reiserfs_proc_info_global_init(void)
  2620. {
  2621. return 0;
  2622. }
  2623. static inline int reiserfs_proc_info_global_done(void)
  2624. {
  2625. return 0;
  2626. }
  2627. #define PROC_EXP( e )
  2628. #define VOID_V ( ( void ) 0 )
  2629. #define PROC_INFO_MAX( sb, field, value ) VOID_V
  2630. #define PROC_INFO_INC( sb, field ) VOID_V
  2631. #define PROC_INFO_ADD( sb, field, val ) VOID_V
  2632. #define PROC_INFO_BH_STAT(sb, bh, n_node_level) VOID_V
  2633. #endif
  2634. /* dir.c */
  2635. extern const struct inode_operations reiserfs_dir_inode_operations;
  2636. extern const struct inode_operations reiserfs_symlink_inode_operations;
  2637. extern const struct inode_operations reiserfs_special_inode_operations;
  2638. extern const struct file_operations reiserfs_dir_operations;
  2639. int reiserfs_readdir_inode(struct inode *, struct dir_context *);
  2640. /* tail_conversion.c */
  2641. int direct2indirect(struct reiserfs_transaction_handle *, struct inode *,
  2642. struct treepath *, struct buffer_head *, loff_t);
  2643. int indirect2direct(struct reiserfs_transaction_handle *, struct inode *,
  2644. struct page *, struct treepath *, const struct cpu_key *,
  2645. loff_t, char *);
  2646. void reiserfs_unmap_buffer(struct buffer_head *);
  2647. /* file.c */
  2648. extern const struct inode_operations reiserfs_file_inode_operations;
  2649. extern const struct file_operations reiserfs_file_operations;
  2650. extern const struct address_space_operations reiserfs_address_space_operations;
  2651. /* fix_nodes.c */
  2652. int fix_nodes(int n_op_mode, struct tree_balance *tb,
  2653. struct item_head *ins_ih, const void *);
  2654. void unfix_nodes(struct tree_balance *);
  2655. /* prints.c */
  2656. void __reiserfs_panic(struct super_block *s, const char *id,
  2657. const char *function, const char *fmt, ...)
  2658. __attribute__ ((noreturn));
  2659. #define reiserfs_panic(s, id, fmt, args...) \
  2660. __reiserfs_panic(s, id, __func__, fmt, ##args)
  2661. void __reiserfs_error(struct super_block *s, const char *id,
  2662. const char *function, const char *fmt, ...);
  2663. #define reiserfs_error(s, id, fmt, args...) \
  2664. __reiserfs_error(s, id, __func__, fmt, ##args)
  2665. void reiserfs_info(struct super_block *s, const char *fmt, ...);
  2666. void reiserfs_debug(struct super_block *s, int level, const char *fmt, ...);
  2667. void print_indirect_item(struct buffer_head *bh, int item_num);
  2668. void store_print_tb(struct tree_balance *tb);
  2669. void print_cur_tb(char *mes);
  2670. void print_de(struct reiserfs_dir_entry *de);
  2671. void print_bi(struct buffer_info *bi, char *mes);
  2672. #define PRINT_LEAF_ITEMS 1 /* print all items */
  2673. #define PRINT_DIRECTORY_ITEMS 2 /* print directory items */
  2674. #define PRINT_DIRECT_ITEMS 4 /* print contents of direct items */
  2675. void print_block(struct buffer_head *bh, ...);
  2676. void print_bmap(struct super_block *s, int silent);
  2677. void print_bmap_block(int i, char *data, int size, int silent);
  2678. /*void print_super_block (struct super_block * s, char * mes);*/
  2679. void print_objectid_map(struct super_block *s);
  2680. void print_block_head(struct buffer_head *bh, char *mes);
  2681. void check_leaf(struct buffer_head *bh);
  2682. void check_internal(struct buffer_head *bh);
  2683. void print_statistics(struct super_block *s);
  2684. char *reiserfs_hashname(int code);
  2685. /* lbalance.c */
  2686. int leaf_move_items(int shift_mode, struct tree_balance *tb, int mov_num,
  2687. int mov_bytes, struct buffer_head *Snew);
  2688. int leaf_shift_left(struct tree_balance *tb, int shift_num, int shift_bytes);
  2689. int leaf_shift_right(struct tree_balance *tb, int shift_num, int shift_bytes);
  2690. void leaf_delete_items(struct buffer_info *cur_bi, int last_first, int first,
  2691. int del_num, int del_bytes);
  2692. void leaf_insert_into_buf(struct buffer_info *bi, int before,
  2693. struct item_head * const inserted_item_ih,
  2694. const char * const inserted_item_body,
  2695. int zeros_number);
  2696. void leaf_paste_in_buffer(struct buffer_info *bi, int pasted_item_num,
  2697. int pos_in_item, int paste_size,
  2698. const char * const body, int zeros_number);
  2699. void leaf_cut_from_buffer(struct buffer_info *bi, int cut_item_num,
  2700. int pos_in_item, int cut_size);
  2701. void leaf_paste_entries(struct buffer_info *bi, int item_num, int before,
  2702. int new_entry_count, struct reiserfs_de_head *new_dehs,
  2703. const char *records, int paste_size);
  2704. /* ibalance.c */
  2705. int balance_internal(struct tree_balance *, int, int, struct item_head *,
  2706. struct buffer_head **);
  2707. /* do_balance.c */
  2708. void do_balance_mark_leaf_dirty(struct tree_balance *tb,
  2709. struct buffer_head *bh, int flag);
  2710. #define do_balance_mark_internal_dirty do_balance_mark_leaf_dirty
  2711. #define do_balance_mark_sb_dirty do_balance_mark_leaf_dirty
  2712. void do_balance(struct tree_balance *tb, struct item_head *ih,
  2713. const char *body, int flag);
  2714. void reiserfs_invalidate_buffer(struct tree_balance *tb,
  2715. struct buffer_head *bh);
  2716. int get_left_neighbor_position(struct tree_balance *tb, int h);
  2717. int get_right_neighbor_position(struct tree_balance *tb, int h);
  2718. void replace_key(struct tree_balance *tb, struct buffer_head *, int,
  2719. struct buffer_head *, int);
  2720. void make_empty_node(struct buffer_info *);
  2721. struct buffer_head *get_FEB(struct tree_balance *);
  2722. /* bitmap.c */
  2723. /*
  2724. * structure contains hints for block allocator, and it is a container for
  2725. * arguments, such as node, search path, transaction_handle, etc.
  2726. */
  2727. struct __reiserfs_blocknr_hint {
  2728. /* inode passed to allocator, if we allocate unf. nodes */
  2729. struct inode *inode;
  2730. sector_t block; /* file offset, in blocks */
  2731. struct in_core_key key;
  2732. /*
  2733. * search path, used by allocator to deternine search_start by
  2734. * various ways
  2735. */
  2736. struct treepath *path;
  2737. /*
  2738. * transaction handle is needed to log super blocks
  2739. * and bitmap blocks changes
  2740. */
  2741. struct reiserfs_transaction_handle *th;
  2742. b_blocknr_t beg, end;
  2743. /*
  2744. * a field used to transfer search start value (block number)
  2745. * between different block allocator procedures
  2746. * (determine_search_start() and others)
  2747. */
  2748. b_blocknr_t search_start;
  2749. /*
  2750. * is set in determine_prealloc_size() function,
  2751. * used by underlayed function that do actual allocation
  2752. */
  2753. int prealloc_size;
  2754. /*
  2755. * the allocator uses different polices for getting disk
  2756. * space for formatted/unformatted blocks with/without preallocation
  2757. */
  2758. unsigned formatted_node:1;
  2759. unsigned preallocate:1;
  2760. };
  2761. typedef struct __reiserfs_blocknr_hint reiserfs_blocknr_hint_t;
  2762. int reiserfs_parse_alloc_options(struct super_block *, char *);
  2763. void reiserfs_init_alloc_options(struct super_block *s);
  2764. /*
  2765. * given a directory, this will tell you what packing locality
  2766. * to use for a new object underneat it. The locality is returned
  2767. * in disk byte order (le).
  2768. */
  2769. __le32 reiserfs_choose_packing(struct inode *dir);
  2770. void show_alloc_options(struct seq_file *seq, struct super_block *s);
  2771. int reiserfs_init_bitmap_cache(struct super_block *sb);
  2772. void reiserfs_free_bitmap_cache(struct super_block *sb);
  2773. void reiserfs_cache_bitmap_metadata(struct super_block *sb, struct buffer_head *bh, struct reiserfs_bitmap_info *info);
  2774. struct buffer_head *reiserfs_read_bitmap_block(struct super_block *sb, unsigned int bitmap);
  2775. int is_reusable(struct super_block *s, b_blocknr_t block, int bit_value);
  2776. void reiserfs_free_block(struct reiserfs_transaction_handle *th, struct inode *,
  2777. b_blocknr_t, int for_unformatted);
  2778. int reiserfs_allocate_blocknrs(reiserfs_blocknr_hint_t *, b_blocknr_t *, int,
  2779. int);
  2780. static inline int reiserfs_new_form_blocknrs(struct tree_balance *tb,
  2781. b_blocknr_t * new_blocknrs,
  2782. int amount_needed)
  2783. {
  2784. reiserfs_blocknr_hint_t hint = {
  2785. .th = tb->transaction_handle,
  2786. .path = tb->tb_path,
  2787. .inode = NULL,
  2788. .key = tb->key,
  2789. .block = 0,
  2790. .formatted_node = 1
  2791. };
  2792. return reiserfs_allocate_blocknrs(&hint, new_blocknrs, amount_needed,
  2793. 0);
  2794. }
  2795. static inline int reiserfs_new_unf_blocknrs(struct reiserfs_transaction_handle
  2796. *th, struct inode *inode,
  2797. b_blocknr_t * new_blocknrs,
  2798. struct treepath *path,
  2799. sector_t block)
  2800. {
  2801. reiserfs_blocknr_hint_t hint = {
  2802. .th = th,
  2803. .path = path,
  2804. .inode = inode,
  2805. .block = block,
  2806. .formatted_node = 0,
  2807. .preallocate = 0
  2808. };
  2809. return reiserfs_allocate_blocknrs(&hint, new_blocknrs, 1, 0);
  2810. }
  2811. #ifdef REISERFS_PREALLOCATE
  2812. static inline int reiserfs_new_unf_blocknrs2(struct reiserfs_transaction_handle
  2813. *th, struct inode *inode,
  2814. b_blocknr_t * new_blocknrs,
  2815. struct treepath *path,
  2816. sector_t block)
  2817. {
  2818. reiserfs_blocknr_hint_t hint = {
  2819. .th = th,
  2820. .path = path,
  2821. .inode = inode,
  2822. .block = block,
  2823. .formatted_node = 0,
  2824. .preallocate = 1
  2825. };
  2826. return reiserfs_allocate_blocknrs(&hint, new_blocknrs, 1, 0);
  2827. }
  2828. void reiserfs_discard_prealloc(struct reiserfs_transaction_handle *th,
  2829. struct inode *inode);
  2830. void reiserfs_discard_all_prealloc(struct reiserfs_transaction_handle *th);
  2831. #endif
  2832. /* hashes.c */
  2833. __u32 keyed_hash(const signed char *msg, int len);
  2834. __u32 yura_hash(const signed char *msg, int len);
  2835. __u32 r5_hash(const signed char *msg, int len);
  2836. #define reiserfs_set_le_bit __set_bit_le
  2837. #define reiserfs_test_and_set_le_bit __test_and_set_bit_le
  2838. #define reiserfs_clear_le_bit __clear_bit_le
  2839. #define reiserfs_test_and_clear_le_bit __test_and_clear_bit_le
  2840. #define reiserfs_test_le_bit test_bit_le
  2841. #define reiserfs_find_next_zero_le_bit find_next_zero_bit_le
  2842. /*
  2843. * sometimes reiserfs_truncate may require to allocate few new blocks
  2844. * to perform indirect2direct conversion. People probably used to
  2845. * think, that truncate should work without problems on a filesystem
  2846. * without free disk space. They may complain that they can not
  2847. * truncate due to lack of free disk space. This spare space allows us
  2848. * to not worry about it. 500 is probably too much, but it should be
  2849. * absolutely safe
  2850. */
  2851. #define SPARE_SPACE 500
  2852. /* prototypes from ioctl.c */
  2853. long reiserfs_ioctl(struct file *filp, unsigned int cmd, unsigned long arg);
  2854. long reiserfs_compat_ioctl(struct file *filp,
  2855. unsigned int cmd, unsigned long arg);
  2856. int reiserfs_unpack(struct inode *inode, struct file *filp);