reiserfs.h 117 KB

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