CHANGES.txt 81 KB

123456789101112131415161718192021222324252627282930313233343536373839404142434445464748495051525354555657585960616263646566676869707172737475767778798081828384858687888990919293949596979899100101102103104105106107108109110111112113114115116117118119120121122123124125126127128129130131132133134135136137138139140141142143144145146147148149150151152153154155156157158159160161162163164165166167168169170171172173174175176177178179180181182183184185186187188189190191192193194195196197198199200201202203204205206207208209210211212213214215216217218219220221222223224225226227228229230231232233234235236237238239240241242243244245246247248249250251252253254255256257258259260261262263264265266267268269270271272273274275276277278279280281282283284285286287288289290291292293294295296297298299300301302303304305306307308309310311312313314315316317318319320321322323324325326327328329330331332333334335336337338339340341342343344345346347348349350351352353354355356357358359360361362363364365366367368369370371372373374375376377378379380381382383384385386387388389390391392393394395396397398399400401402403404405406407408409410411412413414415416417418419420421422423424425426427428429430431432433434435436437438439440441442443444445446447448449450451452453454455456457458459460461462463464465466467468469470471472473474475476477478479480481482483484485486487488489490491492493494495496497498499500501502503504505506507508509510511512513514515516517518519520521522523524525526527528529530531532533534535536537538539540541542543544545546547548549550551552553554555556557558559560561562563564565566567568569570571572573574575576577578579580581582583584585586587588589590591592593594595596597598599600601602603604605606607608609610611612613614615616617618619620621622623624625626627628629630631632633634635636637638639640641642643644645646647648649650651652653654655656657658659660661662663664665666667668669670671672673674675676677678679680681682683684685686687688689690691692693694695696697698699700701702703704705706707708709710711712713714715716717718719720721722723724725726727728729730731732733734735736737738739740741742743744745746747748749750751752753754755756757758759760761762763764765766767768769770771772773774775776777778779780781782783784785786787788789790791792793794795796797798799800801802803804805806807808809810811812813814815816817818819820821822823824825826827828829830831832833834835836837838839840841842843844845846847848849850851852853854855856857858859860861862863864865866867868869870871872873874875876877878879880881882883884885886887888889890891892893894895896897898899900901902903904905906907908909910911912913914915916917918919920921922923924925926927928929930931932933934935936937938939940941942943944945946947948949950951952953954955956957958959960961962963964965966967968969970971972973974975976977978979980981982983984985986987988989990991992993994995996997998999100010011002100310041005100610071008100910101011101210131014101510161017101810191020102110221023102410251026102710281029103010311032103310341035103610371038103910401041104210431044104510461047104810491050105110521053105410551056105710581059106010611062106310641065106610671068106910701071107210731074107510761077107810791080108110821083108410851086108710881089109010911092109310941095109610971098109911001101110211031104110511061107110811091110111111121113111411151116111711181119112011211122112311241125112611271128112911301131113211331134113511361137113811391140114111421143114411451146114711481149115011511152115311541155115611571158115911601161116211631164116511661167116811691170117111721173117411751176117711781179118011811182118311841185118611871188118911901191119211931194119511961197119811991200120112021203120412051206120712081209121012111212121312141215121612171218121912201221122212231224122512261227122812291230123112321233123412351236123712381239124012411242124312441245124612471248124912501251125212531254125512561257125812591260126112621263126412651266126712681269127012711272127312741275127612771278127912801281128212831284128512861287128812891290129112921293129412951296129712981299130013011302130313041305130613071308130913101311131213131314131513161317131813191320132113221323132413251326132713281329133013311332133313341335133613371338133913401341134213431344134513461347134813491350135113521353135413551356135713581359136013611362136313641365136613671368136913701371137213731374137513761377137813791380138113821383138413851386138713881389139013911392139313941395139613971398139914001401140214031404140514061407140814091410141114121413141414151416141714181419142014211422142314241425142614271428142914301431143214331434143514361437143814391440144114421443144414451446144714481449145014511452145314541455145614571458145914601461146214631464146514661467146814691470147114721473147414751476147714781479148014811482148314841485148614871488148914901491149214931494149514961497149814991500150115021503150415051506150715081509151015111512151315141515151615171518151915201521152215231524152515261527152815291530153115321533153415351536153715381539154015411542154315441545154615471548154915501551155215531554155515561557155815591560156115621563156415651566156715681569157015711572157315741575157615771578157915801581158215831584158515861587158815891590159115921593159415951596159715981599160016011602160316041605160616071608160916101611161216131614161516161617161816191620162116221623162416251626162716281629163016311632163316341635163616371638163916401641164216431644164516461647164816491650165116521653165416551656165716581659166016611662166316641665166616671668166916701671167216731674167516761677167816791680168116821683168416851686168716881689169016911692169316941695169616971698169917001701170217031704170517061707170817091710171117121713171417151716171717181719172017211722172317241725172617271728172917301731173217331734173517361737173817391740174117421743174417451746174717481749175017511752175317541755175617571758175917601761176217631764176517661767176817691770177117721773177417751776177717781779178017811782178317841785178617871788178917901791179217931794179517961797179817991800180118021803180418051806180718081809181018111812181318141815181618171818181918201821182218231824182518261827182818291830183118321833183418351836183718381839184018411842184318441845184618471848184918501851185218531854185518561857185818591860186118621863186418651866186718681869187018711872187318741875187618771878187918801881188218831884188518861887188818891890189118921893189418951896189718981899190019011902190319041905190619071908190919101911191219131914191519161917191819191920192119221923192419251926192719281929193019311932193319341935193619371938193919401941194219431944194519461947194819491950195119521953195419551956195719581959196019611962196319641965196619671968196919701971197219731974197519761977197819791980198119821983198419851986198719881989199019911992199319941995199619971998199920002001200220032004200520062007200820092010201120122013201420152016201720182019202020212022202320242025202620272028202920302031203220332034203520362037203820392040204120422043204420452046204720482049205020512052205320542055205620572058205920602061206220632064206520662067206820692070207120722073207420752076207720782079208020812082208320842085208620872088208920902091209220932094209520962097209820992100210121022103210421052106210721082109211021112112211321142115211621172118211921202121212221232124212521262127212821292130213121322133213421352136213721382139214021412142214321442145214621472148
  1. Hadoop MapReduce Change Log
  2. Release 0.22.0 - Unreleased
  3. INCOMPATIBLE CHANGES
  4. MAPREDUCE-1866. Removes deprecated class
  5. org.apache.hadoop.streaming.UTF8ByteArrayUtils. (amareshwari)
  6. MAPREDUCE-1664. Changes the behaviour of the combination of job-acls
  7. when they function together with queue-acls. (Ravi Gummadi via vinodkv)
  8. NEW FEATURES
  9. MAPREDUCE-1804. Stress-test tool for HDFS introduced in HDFS-708.
  10. (Joshua Harlow via shv)
  11. MAPREDUCE-220. Collect cpu and memory statistics per task. (Scott Chen via
  12. acmurthy)
  13. MAPREDUCE-1970. Reed-Solomon code implementation for HDFS RAID.
  14. (Scott Chen via dhruba)
  15. MAPREDUCE-2169. Integrated Reed-Solomon code with RaidNode. (Ramkumar
  16. Vadali via schen)
  17. IMPROVEMENTS
  18. MAPREDUCE-2141. Add an "extra data" field to Task for use by Mesos. (matei)
  19. MAPREDUCE-2140. Regenerate fair scheduler design doc PDF. (matei)
  20. MAPREDUCE-1546. Redirect all job pages to corresponding history page
  21. if job is not in JT memory. (Scott Chen via sharad)
  22. MAPREDUCE-1092. Enable assertions for unit tests. (Eli Collins via
  23. cdouglas)
  24. MAPREDUCE-1680. Add a metric recording JobTracker heartbeats processed.
  25. (Dick King via cdouglas)
  26. MAPREDUCE-1761. FairScheduler allows separate configuration of node
  27. and rack locality wait time (Scott Chen via dhruba)
  28. MAPREDUCE-1539. authorization checks for inter-server protocol
  29. (based on HADOOP-6600) (Boris Shkolnik via shv)
  30. MAPREDUCE-1798. Names the configuration keys for the Kerberos
  31. principals better. (Boris Shkolnik via ddas)
  32. MAPREDUCE-1773. streaming doesn't support jobclient.output.filter.
  33. (Amareshwari Sriramadasu via vinodkv)
  34. MAPREDUCE-1785. Add streaming config option for not emitting the key.
  35. (Eli Collins via sharad)
  36. MAPREDUCE-572. If #link is missing from uri format of -cacheArchive
  37. then streaming does not throw error. (Amareshwari Sriramadasu via
  38. vinodkv)
  39. MAPREDUCE-1545. Add timestamps for first task type launched in job summary.
  40. (Luke Lu via cdouglas)
  41. MAPREDUCE-1543. Add an audit log for authentication events. (Amar Kamat and
  42. Luke Lu via cdouglas)
  43. MAPREDUCE-1762. Add ability to set values of task counters. (Scott Chen via
  44. cdouglas)
  45. MAPREDUCE-1533. Reduce overhead of logging and string manipulation during
  46. heartbeat processing. (Amar Kamat and Dick King via cdouglas)
  47. MAPREDUCE-1516. JobTracker issues delegation tokens only if the user's
  48. authentication is Kerberos. (Jitendra Pandey via ddas)
  49. MAPREDUCE-647. Update distcp forrest documentation to reflect the changes
  50. of HADOOP-5472, MAPREDUCE-642 and HADOOP-5620. (Rodrigo Schmidt via
  51. szetszwo)
  52. MAPREDUCE-1851. Documents configuration parameters in streaming.
  53. (amareshwari)
  54. MAPREDUCE-1868. Add a read and connection timeout to JobClient while
  55. pulling tasklogs. (Krishna Ramachandran via acmurthy)
  56. MAPREDUCE-1778. Ensure failure to setup CompletedJobStatusStore is not
  57. silently ignored by the JobTracker. (Krishna Ramachandran via acmurthy)
  58. MAPREDUCE-1850. Includes job submit host information (name and ip) in
  59. jobconf and jobdetails display (Krishna Ramachandran via amareshwari)
  60. MAPREDUCE-1893. Slive with multiple reducers. (shv)
  61. MAPREDUCE-1248. Fixes redudant memory copying in StreamKeyValUtil.
  62. (Ruibang He via amareshwari)
  63. MAPREDUCE-1840. Enhancements to Gridmix benchmark simulating user
  64. diversity, queue replay, and task duration for JobTracker load testing.
  65. Also includes compatibility with security enhancements, and scalability
  66. improvements. (Amar Kamat, Rahul Singh, Hong Tang, and cdouglas)
  67. MAPREDUCE-1848. Put number of speculative, data local, rack local
  68. tasks in JobTracker metrics. (Scott Chen via dhruba)
  69. MAPREDUCE-1935. Makes the Distcp to work in a secure environment.
  70. (Boris Shkolnik via ddas)
  71. MAPREDUCE-1945. The MapReduce component for HADOOP-6632.
  72. (Kan Zhang & Jitendra Pandey via ddas)
  73. MAPREDUCE-1936. Modify Gridmix3 to support more tunable parameters for
  74. stress submission and sleep jobs. (Hong Tang via cdouglas)
  75. MAPREDUCE-1733. Makes pipes applications secure. (Jitendra Pandey via ddas)
  76. MAPREDUCE-1566. Adds a configuration attribute using which job clients can
  77. specify a credentials file. The tokens from there will be passed to the job.
  78. (Jitendra Pandey and Owen O'Malley via ddas)
  79. MAPREDUCE-1624. Documents the job credentials and associated details to do
  80. with delegation tokens (on the client side).
  81. (Jitendra Pandey and Devaraj Das via ddas)
  82. MAPREDUCE-1834. TestSimulatorDeterministicReplay timesout on trunk.
  83. (Hong Tang via mahadev)
  84. MAPREDUCE-1993. Fixes test failure
  85. TestTrackerDistributedCacheManagerWithLinuxTaskController. (Devaraj Das
  86. via amareshwari)
  87. MAPREDUCE-1523. Making Mumak work with Capacity-Scheduler (Anirban Das
  88. via mahadev)
  89. MAPREDUCE-1920. Enables completed jobstatus store by default. (Tom White
  90. via amareshwari)
  91. MAPREDUCE-1881. Improve TaskTrackerInstrumentation to enable collection of
  92. advanced metrics. (Matei Zaharia via acmurthy)
  93. MAPREDUCE-1548. Hadoop archives preserve times and other properties from
  94. original files. (Rodrigo Schmidt via dhruba)
  95. MAPREDUCE-1517. Supports streaming job to run in the background. (Bochun Bai
  96. via amareshwari)
  97. MAPREDUCE-1819. RaidNode is now smarter in submitting Raid jobs. (Ramkumar
  98. Vadali via schen)
  99. MAPREDUCE-2132. A command line option in RaidShell to fix blocks using raid
  100. MAPREDUCE-2147. Remove redundant lines in JobInProgress ctor.
  101. (Harsh J Chouraria via cutting)
  102. HADOOP-7007. Update the hudson-test-patch ant target to work with the
  103. latest test-patch.sh script (gkesavan)
  104. MAPREDUCE-1818. RaidNode can specify scheduling parameters. (Ramkumar
  105. Vadali via schen)
  106. MAPREDUCE-2051. Contribute a fair scheduler preemption system test.
  107. (Todd Lipcon via tomwhite)
  108. MAPREDUCE-1892. RaidNode can allow layered policies more efficiently.
  109. (Ramkumar Vadali via schen)
  110. MAPREDUCE-1592. Generate Eclipse's .classpath file from Ivy config.
  111. (tomwhite via nigel)
  112. MAPREDUCE-2073. TestTrackerDistributedCacheManager should be up-front
  113. about requirements on build environment. (Todd Lipcon via tomwhite)
  114. MAPREDUCE-2093. Herriot JT and TT clients should vend statistics. (cos)
  115. MAPREDUCE-2167. Faster directory traversal for raid node. (Ramkumar Vadali
  116. via schen)
  117. MAPREDUCE-1931. Gridmix forrest documentation . (Ranjit Mathew via vinodkv).
  118. MAPREDUCE-1878. Add MRUnit documentation. (Aaron Kimball via tomwhite)
  119. MAPREDUCE-2180. Add coverage of fair scheduler servlet to system test (todd)
  120. MAPREDUCE-2260. Remove auto-generated native build files. (rvs via eli)
  121. MAPREDUCE-2314. configure files that are generated as part of the released
  122. tarball need to have executable bit set (rvs via cos)
  123. MAPREDUCE-1159. Limit Job name in web UI to be 80 char long. (Harsh J
  124. Chouraria via szetszwo)
  125. MAPREDUCE-2337. Remove dependence of public MapReduce API on classes in
  126. server package. (tomwhite)
  127. MAPREDUCE-869. Documentation for config to set map/reduce task environment
  128. (Alejandro Abdelnur via todd)
  129. MAPREDUCE-2410. Add entry to streaming FAQ about how streaming reducers
  130. receive keys. (Harsh J Chouraria via todd)
  131. MAPREDUCE-2383. Improve documentation of DistributedCache methods (Harsh J
  132. Chouraria via todd)
  133. MAPREDUCE-2222. Ivy resolve force mode should be turned off by default.
  134. (Luke Lu via tomwhite)
  135. MAPREDUCE-2103. task-controller shouldn't require o-r permissions.
  136. (todd via eli)
  137. MAPREDUCE-2499. MR part of HADOOP-7291. (eli)
  138. MAPREDUCE-2505. Explain how to use ACLs in the fair scheduler.
  139. (matei via eli)
  140. MAPREDUCE-2502. JobSubmitter should use mapreduce.job.maps instead of
  141. its deprecated equivalent. (eli via todd)
  142. MAPREDUCE-2372. TaskLogAppender mechanism shouldn't be set up in
  143. log4j.properties (todd)
  144. MAPREDUCE-2516. Rename webinterface.private.actions to
  145. mapreduce.jobtracker.webinterface.trusted (Ari Rabkin via todd)
  146. HADOOP-7106. Reorganize project SVN layout to "unsplit" the projects.
  147. (todd, nigel)
  148. OPTIMIZATIONS
  149. MAPREDUCE-1354. Enhancements to JobTracker for better performance and
  150. scalability. (Arun C. Murthy & Richard King via acmurthy)
  151. MAPREDUCE-1829. JobInProgress.findSpeculativeTask should use min() to
  152. find the candidate instead of sort(). (Scott Chen via vinodkv)
  153. MAPREDUCE-2026. Make JobTracker.getJobCounters() and
  154. JobInProgress.getCounters() aquire locks in a shorter time period.
  155. (Joydeep Sen Sarma via schen)
  156. BUG FIXES
  157. MAPREDUCE-1845. FairScheduler.tasksToPreempt() can return negative number.
  158. (Scott Chen via matei)
  159. MAPREDUCE-1707. TaskRunner can get NPE in getting ugi from TaskTracker.
  160. (Vinod Kumar Vavilapalli)
  161. MAPREDUCE-1532. Ensures that delegation tokens is obtained as the
  162. actual user when the proxy-user is used for submitting jobs. Also
  163. refactors the DelegationTokenToRenew class. (ddas)
  164. MAPREDUCE-1558. Fixes MRAdmin to look up the principal of the
  165. JobTracker and use that in the RefreshUserToGroupsMapping protocol and
  166. RefreshAuthorizationPolicyProtocol. (Boris Shkolnik via ddas)
  167. MAPREDUCE-1662. Remove unused methods from TaskRunner. (Amareshwari
  168. Sriramadasu via cdouglas)
  169. MAPREDUCE-1617. Use IPv4 stack for unit tests. (Amar Kamat and Luke Lu via
  170. cdouglas)
  171. MAPREDUCE-1599. Fixes MRBench so that it reuses tokens across jobs
  172. correctly. (Jitendra Nath Pandey via ddas)
  173. MAPREDUCE-1836. Refresh for proxy superuser config (mr part for HDFS-1096).
  174. (Boris Shkolnik via shv)
  175. MAPREDUCE-1505. Create RPC client on job submission, not in cstr of Job
  176. instance. (Dick King via cdouglas)
  177. MAPREDUCE-1813. NPE in PipeMapred.MRErrorThread. (Ravi Gummadi via vinodkv)
  178. MAPREDUCE-1225. Fixes DistributedCache to check if the file is fresh or not,
  179. for the first localization also. (Zhong Wang via amareshwari)
  180. MAPREDUCE-1559. Fixes the token renewer to use the JobTracker's
  181. credentials for talking to the NameNode. (ddas)
  182. MAPREDUCE-1492. Delete obsolete har files used on the parity files
  183. of hdfs raid. (Rodrigo Schmidt via dhruba)
  184. MAPREDUCE-1857. Removes unused configuration parameters in streaming.
  185. (amareshwari)
  186. MAPREDUCE-1887. MRAsyncDiskService now properly absolutizes volume root
  187. paths. (Aaron Kimball via zshao)
  188. MAPREDUCE-1863. Fix NPE in Rumen when processing null CDF for failed task
  189. attempts. (Amar Kamat via cdouglas)
  190. MAPREDUCE-1864. Removes uninitialized/unused variables in
  191. org.apache.hadoop.streaming.PipeMapRed. (amareshwari)
  192. MAPREDUCE-1888. Fixes Streaming to override output key and value types,
  193. only if mapper/reducer is a command. (Ravi Gummadi via amareshwari)
  194. MAPREDUCE-577. Fixes duplicate records in StreamXmlRecordReader.
  195. (Ravi Gummadi via amareshwari)
  196. MAPREDUCE-1894. Fixed a bug in DistributedRaidFileSystem.readFully()
  197. that was causing it to loop infinitely. (Ramkumar Vadali via dhruba)
  198. MAPREDUCE-1838. Reduce the time needed for raiding a bunch of files
  199. by randomly assigning files to map tasks. (Ramkumar Vadali via dhruba)
  200. MAPREDUCE-1820. Fix InputSampler to clone sampled keys. (Alex Kozlov via
  201. cdouglas)
  202. MAPREDUCE-1528. Incorporates the changes to the credentials API done in
  203. HADOOP-6845. Also, introduces Credentials in JobConf, and in JobContext.
  204. (Jitendra Pandey and Arun Murthy via ddas)
  205. MAPREDUCE-1865. Rumen should also support jobhistory files generated using
  206. trunk. (Amar Kamat via amareshwari)
  207. MAPREDUCE-1621. Fixes NPE in TextOutputReader.getLastOutput if it has never
  208. read any output. (amareshwari)
  209. MAPREDUCE-1911. Fixes errors in -info message in streaming. (amareshwari)
  210. MAPREDUCE-1772. Corrects errors in streaming documentation in forrest.
  211. (amareshwari)
  212. MAPREDUCE-1925. Fix failing TestRumenJobTraces. (Ravi Gummadi via cdouglas)
  213. MAPREDUCE-1718. Fixes a bug in the construction of jobconf key for the
  214. mapping that the tasks use at runtime for looking up delegation tokens.
  215. (Boris Shkolnik via ddas)
  216. MAPREDUCE-1701. Fixes a problem to do with exception handling in
  217. delegation-token renewals. (Boris Shkolnik via ddas)
  218. MAPREDUCE-1686. Fixes StreamUtil.goodClassOrNull to find classes without
  219. package names. (Paul Burkhardt via amareshwari)
  220. MAPREDUCE-1288. Fixes TrackerDistributedCacheManager to take into account
  221. the owner of the localized file in the mapping from cache URIs to
  222. CacheStatus objects. (ddas)
  223. MAPREDUCE-1982. Fixes Rumen's TraceBuilder to extract job name from either
  224. of configuration properties "mapreduce.job.name" and "mapred.job.name".
  225. (Ravi Gummadi via amareshwari)
  226. MAPREDUCE-1958. The MapReduce part corresponding to the HADOOP-6873.
  227. (Boris Shkolnik & Owen O'Malley via ddas)
  228. MAPREDUCE-1900. TaskTracker and JobTracker closes FileSystems, opened on
  229. behalf of users that it no longer requires. (Kan Zhang and ddas via ddas)
  230. MAPREDUCE-1992. Fixes a problem to do with bringing up the JobTracker in
  231. unsecure mode. (Kan Zhang via ddas)
  232. MAPREDUCE-1999. Fixes ClientProtocol to use the correct
  233. DelegationTokenSelector. (Jitendra Pandey via ddas)
  234. MAPREDUCE-1780. AccessControlList.toString() is used for serialization of
  235. ACL in JobStatus.java. (Ravi Gummadi via vinodkv)
  236. MAPREDUCE-1961. Fix ConcurrentModificationException in Gridmix during
  237. shutdown. (Hong Tang via cdouglas)
  238. MAPREDUCE-2000. Fix parsing of JobHistory lines in Rumen when quotes are
  239. escaped. (Hong Tang via cdouglas)
  240. MAPREDUCE-2022. Fixes compilation errors in TestSubmitJob. (amareshwari)
  241. MAPREDUCE-1670. RAID policies should not scan their own destination path.
  242. (Ramkumar Vadali via dhruba)
  243. MAPREDUCE-1668. RaidNode Hars a directory only if all its parity files
  244. have been created. (Ramkumar Vadali via dhruba)
  245. MAPREDUCE-2021. Fixes duplicate hostnames in CombineFileInputFormat's
  246. split locations. (amareshwari)
  247. MAPREDUCE-1375. Fixes flaky test TestFileArgs. (Todd Lipcon via
  248. amareshwari)
  249. MAPREDUCE-2023. TestDFSIO should not stop reading if curSize != bufferSize.
  250. (Hong Tang via szetszwo)
  251. MAPREDUCE-2031. Fixes test failures TestTaskLauncher and
  252. TestTaskTrackerLocalization. (Ravi Gummadi via amareshwari)
  253. MAPREDUCE-2046. Fixes CombineFileInputFormat to allow splits with size
  254. less than DFS block size. (dhruba borthakur via amareshwari)
  255. MAPREDUCE-1975. Fixes unnecessary InterruptedException log in gridmix.
  256. (Ravi Gummadi via amareshwari)
  257. MAPREDUCE-1597. Fixes CombineFileInputFormat to work with non-splittable
  258. files. (amareshwari)
  259. MAPREDUCE-2032. Fixes TestJobCleanup to cleanup test directory in
  260. tearDown. (Dick King via amareshwari)
  261. MAPREDUCE-1979. Fixes "Output directory already exists" error in gridmix
  262. when gridmix.output.directory is not defined. (Ravi Gummadi via
  263. amareshwari)
  264. MAPREDUCE-1918. Adds documentation to Rumen. (Amar Kamat via amareshwari)
  265. MAPREDUCE-2078. Fixes TraceBuilder to generate traces when a globbed job
  266. history path is given. (Amar Kamat via amareshwari)
  267. MAPREDUCE-1989. Fixes error message in gridmix when user resolver is set
  268. and no user list is given. (Ravi Gummadi via amareshwari)
  269. MAPREDUCE-2067. Distinct minicluster services (e.g. NN and JT) overwrite
  270. each other's service policies. (Aaron T. Myers via tomwhite)
  271. MAPREDUCE-2029. DistributedRaidFileSystem removes itself from FileSystem
  272. cache when it is closed. (Ramkumar Vadali via dhruba)
  273. MAPREDUCE-1816. HAR files used for RAID parity-bite have configurable
  274. partfile size. (Ramkumar Vadali via dhruba)
  275. MAPREDUCE-2082. Fixes Pipes to create the jobtoken file in the right
  276. place. (Jitendra Pandey via ddas)
  277. MAPREDUCE-2095. Fixes Gridmix to run from compressed traces. (Ranjit
  278. Mathew via amareshwari)
  279. MAPREDUCE-1908. DistributedRaidFileSystem now handles ChecksumException
  280. correctly. (Ramkumar Vadali via schen)
  281. MAPREDUCE-2126. JobQueueJobInProgressListener's javadoc is inconsistent
  282. with source code. (Jingguo Yao via tomwhite)
  283. MAPREDUCE-2143. HarFileSystem is able to handle spaces in pathnames.
  284. (Ramkumar Vadali via dhruba)
  285. MAPREDUCE-1867. Remove unused methods in
  286. org.apache.hadoop.streaming.StreamUtil. (amareshwari via tomwhite)
  287. MAPREDUCE-2146. Raid does not affect access time of a source file.
  288. (Ramkumar Vadali via dhruba)
  289. MAPREDUCE-2150. RaidNode periodically fixes corrupt blocks. (Ramkumar Vadali via
  290. schen)
  291. MAPREDUCE-2099. RaidNode recreates outdated parity HARs. (Ramkumar Vadali
  292. via schen)
  293. MAPREDUCE-2173. Fix race condition in TestBlockFixer that was
  294. causing intermittent failure (Patrick Kling via dhruba)
  295. MAPREDUCE-2142. Refactor RaidNode so that the map-reduce component is
  296. clearly separated out. (Patrick Kling via dhruba)
  297. MAPREDUCE-2179. Fix RaidBlockSender compilation failure. (Ramkumar Vadali
  298. via schen)
  299. MAPREDUCE-2034. TestSubmitJob triggers NPE instead of permissions error.
  300. (Todd Lipcon via tomwhite)
  301. MAPREDUCE-2195. New property for local conf directory in
  302. system-test-mapreduce.xml file. (cos)
  303. MAPREDUCE-1783. FairScheduler initializes tasks only when the job can be
  304. run. (Ramkumar Vadali via schen)
  305. MAPREDUCE-2224. Fix synchronization bugs in JvmManager. (todd)
  306. MAPREDUCE-714. JobConf.findContainingJar unescapes unnecessarily on linux (todd)
  307. MAPREDUCE-2096. Secure local filesystem IO from symlink vulnerabilities (todd)
  308. MAPREDUCE-2234. If Localizer can't create task log directory, it should fail
  309. on the spot. (todd)
  310. MAPREDUCE-2219. JobTracker should not try to remove mapred.system.dir
  311. during startup. (todd)
  312. MAPREDUCE-2084. Remove deprecate annotation for package file. The package
  313. classes themselves are already deprecated. This removes an Eclipse error.
  314. (tomwhite via nigel)
  315. MAPREDUCE-1085. For tasks, "ulimit -v -1" is being run when user doesn't
  316. specify a ulimit (todd)
  317. MAPREDUCE-2282. Fix TestMRServerPorts for the changes in
  318. TestHDFSServerPorts. (shv via szetszwo)
  319. MAPREDUCE-2238. Fix permissions handling to avoid leaving undeletable
  320. directories in local dirs. (todd)
  321. MAPREDUCE-2277. TestCapacitySchedulerWithJobTracker needs to wait for jobs
  322. to complete before testing status. (todd)
  323. MAPREDUCE-2253. Servlets should specify content type (todd)
  324. MAPREDUCE-2283. Add timeout for Raid Tests (Ramkumar Vadali via schen)
  325. MAPREDUCE-1754. Replace mapred.persmissions.supergroup with an
  326. acl : mapreduce.cluster.administrators (Amareshwari Sriramadasu via shv)
  327. MAPREDUCE-2256. FairScheduler fairshare preemption from multiple pools may
  328. preempt all tasks from one pool causing that pool to go below fairshare.
  329. (Priyo Mustafi via shv)
  330. MAPREDUCE-2281. MR part of HADOOP-6642. (Chris Douglas, Po Cheung via shv)
  331. MAPREDUCE-2200. TestUmbilicalProtocolWithJobToken is failing without Krb
  332. environment: needs to be conditional. (Konstantin Boudnik via todd)
  333. MAPREDUCE-2077. Resolve name clash in the deprecated
  334. o.a.h.util.MemoryCalculatorPlugin (Luke Lu via shv)
  335. MAPREDUCE-2188. The new API MultithreadedMapper doesn't initialize
  336. RecordReader. (Owen O'Malley via shv)
  337. MAPREDUCE-1915. Fix IndexOutOfBoundsException in IndexCache.
  338. (Priyo Mustafi via shv)
  339. MAPREDUCE-1974. Fix multiple preemtions of the same task in FairScheduler.
  340. (Scott Chen via shv)
  341. MAPREDUCE-2304. Fix TestMRCLI to allow hostname with a hyphen (-).
  342. (Priyo Mustafi via shv)
  343. MAPREDUCE-1825. jobqueue_details.jsp and FairSchedulerServelet should not
  344. call finishedMaps and finishedReduces when job is not initialized.
  345. (Scott Chen via shv)
  346. MAPREDUCE-2285. MiniMRCluster does not start after ant test-patch
  347. (todd)
  348. MAPREDUCE-2311. Fix TestFairScheduler failure (schen)
  349. MAPREDUCE-2315. javadoc is failing in nightly build (todd)
  350. MAPREDUCE-2054. Hierarchical queue implementation broke dynamic queue
  351. addition in Dynamic Scheduler. (Thomas Sandholm via tomwhite)
  352. MAPREDUCE-2272. Job ACL file should not be executable
  353. (Harsh J Chouraria via todd)
  354. MAPREDUCE-2241. ClusterWithLinuxTaskController should accept relative path
  355. on the command line. (todd)
  356. MAPREDUCE-2251. Remove unused mapreduce.job.userhistorylocation config.
  357. (Harsh J Chouraria via todd)
  358. MAPREDUCE-2284. TestLocalRunner.testMultiMaps times out (todd)
  359. MAPREDUCE-2336. Tool-related packages should be in the Tool javadoc group.
  360. (tomwhite)
  361. MAPREDUCE-2394. JUnit output format doesn't propagate into raid contrib
  362. build. (todd)
  363. MAPREDUCE-2392. TaskTracker shutdown in the tests sometimes take 60s.
  364. (tomwhite)
  365. MAPREDUCE-2437. SLive uses only part* files to generating the final report.
  366. (shv)
  367. MAPREDUCE-2428. start-mapred.sh script fails if HADOOP_HOME is not set.
  368. (tomwhite via eli)
  369. MAPREDUCE-2445. Fix TestMiniMRWithDFSWithDistinctUsers to be a valid test.
  370. (todd)
  371. MAPREDUCE-2457. Job submission should inject group.name on the JobTracker
  372. (Alejandro Abdelnur via todd)
  373. MAPREDUCE-2448. NoSuchMethodError:
  374. org.apache.hadoop.hdfs.TestDatanodeBlockScanner.corruptReplica(..) (eli)
  375. MAPREDUCE-2472. Extra whitespace in mapred.child.java.opts breaks JVM
  376. initialization. (Aaron T. Myers via todd)
  377. MAPREDUCE-2222. Ivy resolve force mode should be turned off by default.
  378. (Luke Lu via tomwhite)
  379. MAPREDUCE-2486. Incorrect snapshot dependency published in .pom files
  380. (todd)
  381. MAPREDUCE-2327. MapTask doesn't need to put username information in
  382. SpillRecord. (todd via tomwhite)
  383. MAPREDUCE-2515. MapReduce code references some deprecated options
  384. (Ari Rabkin via todd)
  385. MAPREDUCE-2487. ChainReducer uses MAPPER_BY_VALUE instead of
  386. REDUCER_BY_VALUE. (Devaraj K via todd)
  387. MAPREDUCE-2571. CombineFileInputFormat.getSplits throws a
  388. java.lang.ArrayStoreException. (Bochun Bai via todd)
  389. MAPREDUCE-2127. mapreduce trunk builds are filing on hudson.
  390. (Bruno Mahé via eli)
  391. MAPREDUCE-2752. Build does not pass along properties to contrib builds.
  392. (Joep Rottinghuis via cos)
  393. MAPREDUCE-2753. Generated POMs hardcode dependency on hadoop-common
  394. version 0.22.0-SNAPSHOT (Joep Rottinghuis via cos)
  395. MAPREDUCE-2767. Remove Linux task-controller. (Milind Bhandarkar via shv)
  396. MAPREDUCE-2948. Hadoop streaming test failure, post MR-2767 (mahadev)
  397. MAPREDUCE-2940. Build fails with ant 1.7.0 but works with 1.8.0
  398. (Joep Rottinghuis via shv)
  399. Release 0.21.1 - Unreleased
  400. NEW FEATURES
  401. MAPREDUCE-2040. Forrest Documentation for Dynamic Priority Scheduler.
  402. (Thomas Sandholm via tomwhite)
  403. BUG FIXES
  404. MAPREDUCE-1897. trunk build broken on compile-mapred-test (cos)
  405. MAPREDUCE-1280. Update Eclipse plugin to the new eclipse.jdt API.
  406. (Alex Kozlov via szetszwo)
  407. MAPREDUCE-1984. herriot TestCluster fails because exclusion is not there
  408. (Balaji Rajagopalan via cos)
  409. MAPREDUCE-2090. Clover build doesn't generate per-test coverage. (cos)
  410. MAPREDUCE-2134. ant binary-system is broken in mapreduce project. (cos)
  411. MAPREDUCE-1905. Fixes Context.setStatus() and progress() apis.
  412. (amareshwari)
  413. MAPREDUCE-1809. Ant build changes for Streaming system tests in contrib
  414. projects. (Vinay Kumar Thota via amareshwari)
  415. MAPREDUCE-2223. TestMRCLI might fail on Ubuntu with default /etc/hosts
  416. (cos)
  417. MAPREDUCE-2228. Remove java5 dependencies from build. (cos)
  418. MAPREDUCE-1929. Allow artifacts to be published to the staging Apache Nexus
  419. Maven Repository. (tomwhite)
  420. MAPREDUCE-2317. Fix a NPE in HadoopArchives. (Devaraj K via szetszwo)
  421. Release 0.21.0 - 2010-08-13
  422. INCOMPATIBLE CHANGES
  423. MAPREDUCE-516. Fix the starvation problem in the Capacity Scheduler
  424. when running High RAM Jobs. (Arun Murthy via yhemanth)
  425. MAPREDUCE-358. Change org.apache.hadoop.examples. AggregateWordCount
  426. and org.apache.hadoop.examples.AggregateWordHistogram to use new
  427. mapreduce api. (Amareshwari Sriramadasu via sharad)
  428. MAPREDUCE-245. Change Job and jobcontrol classes to use the List interface
  429. rather than ArrayList in APIs. (Tom White via cdouglas)
  430. MAPREDUCE-766. Enhanced list-blacklisted-trackers to display reasons
  431. for blacklisting a node. (Sreekanth Ramakrishnan via yhemanth)
  432. MAPREDUCE-817. Add a cache for retired jobs with minimal job info and
  433. provide a way to access history file url. (sharad)
  434. MAPREDUCE-711. Moved Distributed Cache from Common to Map/Reduce
  435. project. (Vinod Kumar Vavilapalli via yhemanth)
  436. MAPREDUCE-895. Per the contract elucidated in HADOOP-6201, throw
  437. FileNotFoundException from FileSystem::listStatus rather than returning
  438. null. (Jakob Homan via cdouglas)
  439. MAPREDUCE-479. Provide full task id to map output servlet rather than the
  440. reduce id, only. (Jiaqi Tan via cdouglas)
  441. MAPREDUCE-873. Simplify job recovery. Incomplete jobs are resubmitted on
  442. jobtracker restart. Removes a public constructor in JobInProgress. (sharad)
  443. HADOOP-6230. Moved process tree and memory calculator related classes from
  444. Common to Map/Reduce. (Vinod Kumar Vavilapalli via yhemanth)
  445. MAPREDUCE-157. Refactor job history APIs and change the history format to
  446. JSON. (Jothi Padmanabhan via sharad)
  447. MAPREDUCE-849. Rename configuration properties. (Amareshwari Sriramadasu
  448. via sharad)
  449. MAPREDUCE-1287. Only call the partitioner with more than one reducer.
  450. (cdouglas)
  451. MAPREDUCE-1385. Use the new UserGroupInformation from HADOOP-6299.
  452. (ddas via omalley)
  453. MAPREDUCE-1493. Authorization for job-history pages. (vinodkv)
  454. MAPREDUCE-1607. Task controller may not set permissions for a
  455. task cleanup attempt's log directory (Amareshwari Sriramadasu via vinodkv)
  456. MAPREDUCE-1683. Remove JNI calls from ClusterStatus cstr. (Arun Murthy and
  457. Luke Lu via cdouglas)
  458. MAPREDUCE-1855. Makes the refresh methods (for groups and proxy users)
  459. independent of the client side configuration. (Boris Shkolnik via ddas)
  460. NEW FEATURES
  461. MAPREDUCE-1774. Large-scale Automated Framework (Sharad Agarwal, Sreekanth
  462. Ramakrishnan, Konstantin Boudnik, at all via cos)
  463. MAPREDUCE-706. Support for FIFO pools in the fair scheduler.
  464. (Matei Zaharia)
  465. MAPREDUCE-546. Provide sample fair scheduler config file in conf/ and use
  466. it by default if no other config file is specified. (Matei Zaharia)
  467. MAPREDUCE-551. Preemption support in the Fair Scheduler. (Matei Zaharia)
  468. MAPREDUCE-567. Add a new example MR that always fails. (Philip Zeyliger
  469. via tomwhite)
  470. MAPREDUCE-211. Provides ability to run a health check script on the
  471. tasktracker nodes and blacklist nodes if they are unhealthy.
  472. (Sreekanth Ramakrishnan via yhemanth)
  473. MAPREDUCE-637. Add an example, distbbp, which able to compute the n th bit
  474. of Pi for some large n. (szetszwo)
  475. MAPREDUCE-532. Provide a way to limit the number of used slots
  476. per queue in the capacity scheduler.
  477. (Rahul Kumar Singh via yhemanth)
  478. MAPREDUCE-467. Provide ability to collect statistics about total tasks
  479. and succeeded tasks in different time windows. (sharad)
  480. MAPREDUCE-740. Log a job-summary at the end of a job, while allowing it
  481. to be configured to use a custom appender if desired. (acmurthy)
  482. MAPREDUCE-814. Provide a way to configure completed job history files
  483. to be on HDFS. (sharad)
  484. MAPREDUCE-800. MRUnit should support the new API. (Aaron Kimball via
  485. tomwhite)
  486. MAPREDUCE-798. MRUnit should be able to test a succession of MapReduce
  487. passes. (Aaron Kimball via tomwhite)
  488. MAPREDUCE-768. Provide an option to dump jobtracker configuration in JSON
  489. format to standard output. (V.V.Chaitanya Krishna via yhemanth)
  490. MAPREDUCE-824. Add support for a hierarchy of queues in the capacity
  491. scheduler. (Rahul Kumar Singh via yhemanth)
  492. MAPREDUCE-751. Add Rumen, a tool for extracting statistics from job tracker
  493. logs and generating job traces for simulation and analysis. (Dick King via
  494. cdouglas)
  495. MAPREDUCE-830. Add support for splittable compression to TextInputFormats.
  496. (Abdul Qadeer via cdouglas)
  497. MAPREDUCE-861. Add support for hierarchical queues in the Map/Reduce
  498. framework. (Rahul Kumar Singh via yhemanth)
  499. MAPREDUCE-776. Add Gridmix, a benchmark processing Rumen traces to simulate
  500. a measured mix of jobs on a cluster. (cdouglas)
  501. MAPREDUCE-862. Enhance JobTracker UI to display hierarchical queues.
  502. (V.V.Chaitanya Krishna via yhemanth)
  503. MAPREDUCE-777. Brand new apis to track and query jobs as a
  504. replacement for JobClient. (Amareshwari Sriramadasu via acmurthy)
  505. MAPREDUCE-775. Add native and streaming support for Vertica as an input
  506. or output format taking advantage of parallel read and write properties of
  507. the DBMS. (Omer Trajman via ddas)
  508. MAPREDUCE-679. XML-based metrics as JSP servlet for JobTracker.
  509. (Aaron Kimball via tomwhite)
  510. MAPREDUCE-980. Modify JobHistory to use Avro for serialization. (cutting)
  511. MAPREDUCE-728. Add Mumak, a Hadoop map/reduce simulator. (Arun C Murthy,
  512. Tamas Sarlos, Anirban Dasgupta, Guanying Wang, and Hong Tang via cdouglas)
  513. MAPREDUCE-1383. Automates fetching of delegation tokens in File*Formats
  514. Distributed Cache and Distcp. Also, provides a config
  515. mapreduce.job.hdfs-servers that the jobs can populate with a comma
  516. separated list of namenodes. The job client automatically fetches
  517. delegation tokens from those namenodes. (Boris Shkolnik via ddas)
  518. MAPREDUCE-698. Per-pool task limits for the fair scheduler.
  519. (Kevin Peterson via matei)
  520. MAPREDUCE-1026. Does mutual authentication of the shuffle
  521. transfers using a shared JobTracker generated key.
  522. (Boris Shkolnik via ddas)
  523. MAPREDUCE-744. Introduces the notion of a public distributed cache.
  524. (Devaraj Das)
  525. MAPREDUCE-1338. Introduces the notion of token cache using which
  526. tokens and secrets can be sent by the Job client to the JobTracker.
  527. (Boris Shkolnik via ddas)
  528. HDFS-503. This patch implements an optional layer over HDFS that
  529. implements offline erasure-coding. It can be used to reduce the
  530. total storage requirements of HDFS. (dhruba)
  531. MAPREDUCE-1432. Adds hooks in the jobtracker and tasktracker
  532. for loading the tokens in the user's ugi. This is required
  533. for the copying of files from the hdfs. (ddas)
  534. MAPREDUCE-1335. Adds SASL Kerberos/Digest authentication in MapReduce.
  535. (Kan Zhang via ddas)
  536. MAPREDUCE-1464. Makes a compatible change in JobTokenIdentifier to
  537. account for HADOOP-6510. (Jitendra Nath Pandey via ddas)
  538. MAPREDUCE-1433. Add a delegation token for MapReduce. (omalley)
  539. MAPREDUCE-1307. Introduces the Job level ACLs feature.
  540. (Vinod Kumar Vavilapalli via ddas)
  541. MAPREDUCE-1430. JobTracker automatically renews delegation tokens for jobs.
  542. (Boris Shkolnik via ddas)
  543. MAPREDUCE-1455. Introduces job-level authorization for mapreduce servlets.
  544. (Ravi Gummadi via vinodkv)
  545. IMPROVEMENTS
  546. MAPREDUCE-463. Makes job setup and cleanup tasks as optional.
  547. (Amareshwari Sriramadasu via sharad)
  548. MAPREDUCE-502. Allow jobtracker to be configured with zero completed jobs
  549. in memory. (Amar Kamat via sharad)
  550. MAPREDUCE-416. Moves the history file to a "done" folder whenever a job
  551. completes. (Amar Kamat via ddas)
  552. MAPREDUCE-646. Increase srcfilelist replication number in dictcp job.
  553. (Ravi Gummadi via szetszwo)
  554. HADOOP-6106. Updated hadoop-core and test jars from hudson trunk
  555. build #12. (Giridharan Kesavan)
  556. MAPREDUCE-642. A option to distcp that allows preserving the full
  557. source path of a file in the specified destination directory.
  558. (Rodrigo Schmidt via dhruba)
  559. MAPREDUCE-686. Move TestSpeculativeExecution.Fake* into a separate class
  560. so that it can be used by other tests. (Jothi Padmanabhan via sharad)
  561. MAPREDUCE-625. Modify TestTaskLimits to improve execution time.
  562. (Jothi Padmanabhan via sharad)
  563. MAPREDUCE-465. Deprecate o.a.h.mapred.lib.MultithreadedMapRunner and add
  564. test for o.a.h.mapreduce.lib.MultithreadedMapper.
  565. (Amareshwari Sriramadasu via sharad)
  566. MAPREDUCE-701. Improves the runtime of the TestRackAwareTaskPlacement
  567. by making it a unit test. (Jothi Padmanabhan via ddas)
  568. MAPREDUCE-371. Change KeyFieldBasedComparator and KeyFieldBasedPartitioner
  569. to use new api. (Amareshwari Sriramadasu via sharad)
  570. MAPREDUCE-623. Resolve javac warnings in mapreduce. (Jothi Padmanabhan
  571. via sharad)
  572. MAPREDUCE-655. Change KeyValueLineRecordReader and KeyValueTextInputFormat
  573. to use new mapreduce api. (Amareshwari Sriramadasu via sharad)
  574. MAPREDUCE-632. Merge TestCustomOutputCommitter with
  575. TestCommandLineJobSubmission. (Jothi Padmanabhan via sharad)
  576. MAPREDUCE-627. Improves execution time of TestTrackerBlacklistAcrossJobs.
  577. (Jothi Padmanabhan via ddas)
  578. MAPREDUCE-630. Improves execution time of TestKillCompletedJob.
  579. (Jothi Padmanabhan via ddas)
  580. MAPREDUCE-626. Improves the execution time of TestLostTracker.
  581. (Jothi Padmanabhan via ddas)
  582. MAPREDUCE-353. Makes the shuffle read and connection timeouts
  583. configurable. (Ravi Gummadi via ddas)
  584. MAPREDUCE-739. Allow relative paths to be created in archives. (Mahadev
  585. Konar via cdouglas)
  586. MAPREDUCE-772. Merge HADOOP-4010 changes to LineRecordReader into mapreduce
  587. package. (Abdul Qadeer via cdouglas)
  588. MAPREDUCE-785. Separate sub-test of TestReduceFetch to be included in
  589. MR-670. (Jothi Padmanabhan via cdouglas)
  590. MAPREDUCE-784. Modify TestUserDefinedCounters to use LocalJobRunner
  591. instead of MiniMR. (Jothi Padmanabhan via sharad)
  592. HADOOP-6160. Fix releaseaudit target to run on specific directories.
  593. (gkesavan)
  594. MAPREDUCE-782. Use PureJavaCrc32 in SpillRecord. (Todd Lipcon via
  595. szetszwo)
  596. MAPREDUCE-369. Change org.apache.hadoop.mapred.lib.MultipleInputs to
  597. use new api. (Amareshwari Sriramadasu via sharad)
  598. MAPREDUCE-373. Change org.apache.hadoop.mapred.lib.FieldSelectionMapReduce
  599. to use new api. (Amareshwari Sriramadasu via sharad)
  600. MAPREDUCE-628. Improves the execution time of TestJobInProgress.
  601. (Jothi Padmanabhan via ddas)
  602. MAPREDUCE-793. Creates a new test that consolidates a few tests to
  603. include in the commit-test list. (Jothi Padmanabhan via ddas)
  604. MAPREDUCE-797. Adds combiner support to MRUnit MapReduceDriver.
  605. (Aaron Kimball via johan)
  606. MAPREDUCE-656. Change org.apache.hadoop.mapred.SequenceFile* classes
  607. to use new mapreduce api. (Amareshwari Sriramadasu via sharad)
  608. MAPREDUCE-670. Creates ant target for 10 mins patch test build.
  609. (Jothi Padmanabhan via gkesavan)
  610. MAPREDUCE-375. Change org.apache.hadoop.mapred.lib.NLineInputFormat
  611. and org.apache.hadoop.mapred.MapFileOutputFormat to use new api.
  612. (Amareshwari Sriramadasu via ddas)
  613. MAPREDUCE-779. Added node health failure counts into
  614. JobTrackerStatistics. (Sreekanth Ramakrishnan via yhemanth)
  615. MAPREDUCE-842. Setup secure permissions for localized job files,
  616. intermediate outputs and log files on tasktrackers.
  617. (Vinod Kumar Vavilapalli via yhemanth)
  618. MAPREDUCE-478. Allow map and reduce jvm parameters, environment variables
  619. and ulimit to be set separately.
  620. Configuration changes:
  621. add mapred.map.child.java.opts
  622. add mapred.reduce.child.java.opts
  623. add mapred.map.child.env
  624. add mapred.reduce.child.ulimit
  625. add mapred.map.child.env
  626. add mapred.reduce.child.ulimit
  627. deprecated mapred.child.java.opts
  628. deprecated mapred.child.env
  629. deprecated mapred.child.ulimit
  630. (acmurthy)
  631. MAPREDUCE-767. Remove the dependence on the CLI 2.0 snapshot.
  632. (Amar Kamat via omalley)
  633. MAPREDUCE-712. Minor efficiency tweaks to RandomTextWriter. (cdouglas)
  634. MAPREDUCE-870. Remove the job retire thread and the associated
  635. config parameters. (sharad)
  636. MAPREDUCE-874. Rename the PiEstimator example to QuasiMonteCarlo.
  637. (szetszwo)
  638. MAPREDUCE-336. Allow logging level of map/reduce tasks to be configurable.
  639. Configuration changes:
  640. add mapred.map.child.log.level
  641. add mapred.reduce.child.log.level
  642. (acmurthy)
  643. MAPREDUCE-355. Update mapred.join package to use the new API. (Amareshwari
  644. Sriramadasu via cdouglas)
  645. HADOOP-6184. Updated hadoop common and test jars to get the new API
  646. in Configuration for dumping in JSON format from Hudson trunk build #68.
  647. (yhemanth)
  648. MAPREDUCE-476. Extend DistributedCache to work locally (LocalJobRunner).
  649. (Philip Zeyliger via tomwhite)
  650. MAPREDUCE-825. JobClient completion poll interval of 5s causes slow tests
  651. in local mode. (Aaron Kimball via tomwhite)
  652. MAPREDUCE-910. Support counters in MRUnit. (Aaron Kimball via cdouglas)
  653. MAPREDUCE-788. Update gridmix2 to use the new API (Amareshwari Sriramadasu
  654. via cdouglas)
  655. MAPREDUCE-875. Make DBRecordReader execute queries lazily. (Aaron Kimball
  656. via enis)
  657. MAPREDUCE-318. Modularizes the shuffle code. (Jothi Padmanabhan and
  658. Arun Murthy via ddas)
  659. MAPREDUCE-936. Allow a load difference for fairshare scheduler.
  660. (Zheng Shao via dhruba)
  661. MAPREDUCE-370. Update MultipleOutputs to use the API, merge funcitonality
  662. of MultipleOutputFormat. (Amareshwari Sriramadasu via cdouglas)
  663. MAPREDUCE-898. Changes DistributedCache to use the new API.
  664. (Amareshwari Sriramadasu via ddas)
  665. MAPREDUCE-144. Includes dump of the process tree in task diagnostics when
  666. a task is killed due to exceeding memory limits.
  667. (Vinod Kumar Vavilapalli via yhemanth)
  668. MAPREDUCE-945. Modifies MRBench and TestMapRed to use ToolRunner so that
  669. options such as queue name can be passed via command line.
  670. (Sreekanth Ramakrishnan via yhemanth)
  671. MAPREDUCE-963. Deprecate o.a.h.mapred.FileAlreadyExistsException and
  672. replace it with o.a.h.fs.FileAlreadyExistsException. (Boris Shkolnik
  673. via szetszwo)
  674. MAPREDUCE-960. Remove an unnecessary intermediate copy and obsolete API
  675. from KeyValueLineRecordReader. (cdouglas)
  676. MAPREDUCE-930. Modify Rumen to resolve paths in the canonical way, rather
  677. than defaulting to the local filesystem. (cdouglas)
  678. MAPREDUCE-944. Extend the LoadManager API of the fair-share scheduler
  679. to support regulating tasks for a job based on resources currently in use
  680. by that job. (dhruba)
  681. MAPREDUCE-973. Move FailJob and SleepJob from examples to test. (cdouglas
  682. via omalley)
  683. MAPREDUCE-966. Modify Rumen to clean up interfaces and simplify integration
  684. with other tools. (Hong Tang via cdouglas)
  685. MAPREDUCE-856. Setup secure permissions for distributed cache files.
  686. (Vinod Kumar Vavilapalli via yhemanth)
  687. MAPREDUCE-885. More efficient SQL queries for DBInputFormat. (Aaron Kimball
  688. via enis)
  689. MAPREDUCE-284. Enables ipc.client.tcpnodelay in Tasktracker's Child.
  690. (Ravi Gummadi via sharad)
  691. MAPREDUCE-916. Split the documentation to match the project split.
  692. (Corinne Chandel via omalley)
  693. MAPREDUCE-649. Validate a copy by comparing the source and destination
  694. checksums in distcp. Also adds an intra-task retry mechanism for errors
  695. detected during the copy. (Ravi Gummadi via cdouglas)
  696. MAPREDUCE-654. Add a -dryrun option to distcp printing a summary of the
  697. file data to be copied, without actually performing the copy. (Ravi Gummadi
  698. via cdouglas)
  699. MAPREDUCE-664. Display the number of files deleted by distcp when the
  700. -delete option is specified. (Ravi Gummadi via cdouglas)
  701. MAPREDUCE-781. Let the name of distcp jobs be configurable. (Venkatesh S
  702. via cdouglas)
  703. MAPREDUCE-975. Add an API in job client to get the history file url for
  704. a given job id. (sharad)
  705. MAPREDUCE-905. Add Eclipse launch tasks for MapReduce. (Philip Zeyliger
  706. via tomwhite)
  707. MAPREDUCE-277. Makes job history counters available on the job history
  708. viewers. (Jothi Padmanabhan via ddas)
  709. MAPREDUCE-893. Provides an ability to refresh queue configuration
  710. without restarting the JobTracker.
  711. (Vinod Kumar Vavilapalli and Rahul Kumar Singh via yhemanth)
  712. MAPREDUCE-1011. Add build.properties to svn and git ignore. (omalley)
  713. MAPREDUCE-954. Change Map-Reduce context objects to be interfaces.
  714. (acmurthy)
  715. MAPREDUCE-639. Change Terasort example to reflect the 2009 updates.
  716. (omalley)
  717. MAPREDUCE-1063. Document gridmix benchmark. (cdouglas)
  718. MAPREDUCE-931. Use built-in interpolation classes for making up task
  719. runtimes in Rumen. (Dick King via cdouglas)
  720. MAPREDUCE-1012. Mark Context interfaces as public evolving. (Tom White via
  721. cdouglas)
  722. MAPREDUCE-971. Document use of distcp when copying to s3, managing timeouts
  723. in particular. (Aaron Kimball via cdouglas)
  724. HDFS-663. DFSIO for append. (shv)
  725. HDFS-641. Move all of the components that depend on map/reduce to
  726. map/reduce. (omalley)
  727. HADOOP-5107. Use Maven ant tasks to publish artifacts. (Giridharan Kesavan
  728. via omalley)
  729. MAPREDUCE-1229. Allow customization of job submission policy in Mumak.
  730. (Hong Tang via cdouglas)
  731. MAPREDUCE-1317. Reduce the memory footprint of Rumen objects by interning
  732. host Strings. (Hong Tang via cdouglas)
  733. MAPREDUCE-1097. Add support for Vertica 3.5 to its contrib module. (Omer
  734. Trajman via cdouglas)
  735. MAPREDUCE-1627. HadoopArchives should not uses a method in DistCp.
  736. (szetszwo)
  737. MAPREDUCE-1198. Alternatively schedule different types of tasks in
  738. fair share scheduler. (Scott Chen via matei)
  739. MAPREDUCE-707. Provide a jobconf property for explicitly assigning a job to
  740. a pool in the Fair Scheduler. (Alan Heirich via matei)
  741. MAPREDUCE-947. Added commitJob and abortJob apis to OutputCommitter.
  742. Enhanced FileOutputCommitter to create a _SUCCESS file for successful
  743. jobs. (Amar Kamat & Jothi Padmanabhan via acmurthy)
  744. MAPREDUCE-1103. Added more metrics to Jobtracker. (sharad)
  745. MAPREDUCE-1048. Add occupied/reserved slot usage summary on jobtracker UI.
  746. (Amareshwari Sriramadasu and Hemanth Yamijala via sharad)
  747. MAPREDUCE-1090. Modified log statement in TaskMemoryManagerThread to
  748. include task attempt id. (yhemanth)
  749. MAPREDUCE-1189. Reduce ivy console output to ovservable level (cos)
  750. MAPREDUCE-1167. ProcfsBasedProcessTree collects rss memory information.
  751. (Scott Chen via dhruba)
  752. MAPREDUCE-1231. Added a new DistCp option, -skipcrccheck, so that the CRC
  753. check during setup can be skipped. (Jothi Padmanabhan via szetszwo)
  754. MAPREDUCE-1190. Add package documentation for BBP example.
  755. (Tsz Wo (Nicholas) Sze via cdouglas)
  756. MAPREDUCE-1119. When tasks fail to report status, show tasks's stack dump
  757. before killing. (Aaron Kimball via tomwhite)
  758. MAPREDUCE-1185. Redirect running job url to history url if job is already
  759. retired. (Amareshwari Sriramadasu and Sharad Agarwal via sharad)
  760. MAPREDUCE-1050. Introduce a mock object testing framework. (tomwhite)
  761. MAPREDUCE-1084. Implementing aspects development and fault injeciton
  762. framework for MapReduce. (Sreekanth Ramakrishnan via cos)
  763. MAPREDUCE-1209. Move common specific part of the test TestReflectionUtils
  764. out of mapred into common. (Todd Lipcon via tomwhite)
  765. MAPREDUCE-967. TaskTracker does not need to fully unjar job jars.
  766. (Todd Lipcon via tomwhite)
  767. MAPREDUCE-1083. Changes in MapReduce so that group information of users
  768. can be refreshed in the JobTracker via command line.
  769. (Boris Shkolnik via ddas)
  770. MAPREDUCE-181. Changes the job submission process to be secure.
  771. (Devaraj Das)
  772. MAPREDUCE-1250. Refactors the JobToken to use Common's Token interface.
  773. (Kan Zhang via ddas)
  774. MAPREDUCE-896. Enhance tasktracker to cleanup files that might have
  775. been created by user tasks with non-writable permissions.
  776. (Ravi Gummadi via yhemanth)
  777. MAPREDUCE-372. Change org.apache.hadoop.mapred.lib.ChainMapper/Reducer
  778. to use new mapreduce api. (Amareshwari Sriramadasu via sharad)
  779. MAPREDUCE-1295. Add a tool in Rumen for folding and manipulating job
  780. traces. (Dick King via cdouglas)
  781. MAPREDUCE-1302. TrackerDistributedCacheManager deletes file
  782. asynchronously, thus reducing task initialization delays.
  783. (Zheng Shao via dhruba)
  784. MAPREDUCE-1218. TaskTrackers send cpu and memory usage of
  785. node to JobTracker. (Scott Chen via dhruba)
  786. MAPREDUCE-847. Fix Releaseaudit warning count to zero
  787. (Giridharan Kesavan)
  788. MAPREDUCE-1337. Use generics in StreamJob to improve readability of that
  789. class. (Kay Kay via cdouglas)
  790. MAPREDUCE-361. Port terasort example to the new mapreduce API. (Amareshwari
  791. Sriramadasu via cdouglas)
  792. MAPREDUCE-1367. LocalJobRunner should support parallel mapper execution.
  793. (Aaron Kimball via tomwhite)
  794. MAPREDUCE-64. Eliminate io.sort.record.percent from MapTask configuration.
  795. (cdouglas)
  796. MAPREDUCE-1440. Replace the long user name in MapReduce with the local
  797. name. (omalley)
  798. MAPREDUCE-1470. Move delegation tokens from HDFS to Common so that
  799. MapReduce can use them too. (omalley)
  800. MAPREDUCE-1425. Reduce memory usage by archive. (mahadev via szetszwo)
  801. MAPREDUCE-1441. Trim whitespace from directory lists pulled from the
  802. configuration. (Todd Lipcon via cdouglas)
  803. MAPREDUCE-1309. Refactor Rumen trace generator to improve code structure
  804. and add extensible support for log formats. (Dick King via cdouglas)
  805. MAPREDUCE-1503. Delegation token renewing and cancelling should provide
  806. meaningful exceptions when there are failures instead of returning
  807. false. (omalley)
  808. HADOOP-6579. Upgrade commons-codec library to 1.4. (omalley)
  809. MAPREDUCE-1423. Improve performance of CombineFileInputFormat when multiple
  810. pools are configured. (Dhruba Borthakur via zshao)
  811. MAPREDUCE-1454. Quote user supplied strings in Tracker servlets. (cdouglas)
  812. MAPREDUCE-1408. Add customizable job submission policies to Gridmix. (Rahul
  813. Singh via cdouglas)
  814. MAPREDUCE-1527. Better warning logged when mapred.queue.names is
  815. overshadowed by mapred-queues.xml. (Hong Tang via acmurthy)
  816. MAPREDUCE-1403. Save the size and number of distributed cache artifacts in
  817. the configuration. (Arun Murthy via cdouglas)
  818. MAPREDUCE-1482. Truncate state string and diagnostic information in
  819. TaskStatus. (Amar Kamat via szetszwo)
  820. MAPREDUCE-1593. [Rumen] Improvements to random seed generation (tamas via
  821. mahadev)
  822. MAPREDUCE-1460. Oracle support in DataDrivenDBInputFormat.
  823. (Aaron Kimball via tomwhite)
  824. MAPREDUCE-1569. Pass configuration through mocked contexts in MRUnit.
  825. (Chris White via cdouglas)
  826. MAPREDUCE-1590. Move HarFileSystem from Hadoop Common to Mapreduce tools.
  827. (mahadev)
  828. MAPREDUCE-1629. Get rid of fakeBlockLocations() on HarFileSystem, since
  829. it's not used (mahadev)
  830. MAPREDUCE-1489. DataDrivenDBInputFormat should not query the database
  831. when generating only one split. (Aaron Kimball via tomwhite)
  832. MAPREDUCE-1514. Add documentation on replication, permissions, new options,
  833. limitations and internals of har. (mahadev via szetszwo)
  834. MAPREDUCE-1428. Make block size and the size of archive created files
  835. configurable. (mahadev via szetszwo)
  836. MAPREDUCE-1656. JobStory should provide queue info. (hong via mahadev)
  837. MAPREDUCE-1466. Record number of files processed in FileInputFormat in the
  838. Configuration for offline analysis. (Luke Lu and Arun Murthy via cdouglas)
  839. MAPREDUCE-1538. TrackerDistributedCacheManager manages the
  840. number of files. (Scott Chen via dhruba)
  841. MAPREDUCE-1673. Scripts to start and stop RaidNode.
  842. (Rodrigo Schmidt via dhruba)
  843. MAPREDUCE-1659. RaidNode writes temp files on configured tmp directory and
  844. add random numbers to their names to avoid conflicts
  845. (Rodrigo Schmidt via dhruba)
  846. MAPREDUCE-1221. Allow admins to control physical memory limits per-task
  847. and per-node. (Scott Chen via acmurthy)
  848. MAPREDUCE-1065. Update mapred tutorial to use the new API. (Aaron Kimball
  849. via cdouglas)
  850. MAPREDUCE-1304. Add a task counter tracking time spent in GC. (Aaron
  851. Kimball via cdouglas)
  852. MAPREDUCE-1570. Add grouping comparators to MRUnit. (Chris White via
  853. cdouglas)
  854. MAPREDUCE-1650. Exclude Private elements from generated MapReduce
  855. Javadoc. (tomwhite)
  856. MAPREDUCE-1625. Improve grouping of packages in Javadoc. (tomwhite)
  857. MAPREDUCE-1417. Forrest documentation should be updated to reflect
  858. the changes in MAPREDUCE-744. (Ravi Gummadi via vinodkv)
  859. MAPREDUCE-1568. TrackerDistributedCacheManager should clean up cache
  860. in a background thread. (Scott Chen via zshao)
  861. MAPREDUCE-1749. Move configuration strings out of JobContext so that it
  862. can be made public stable. (omalley)
  863. MAPREDUCE-1623. Apply audience and stability notations to Hadoop
  864. Map-Reduce. (tomwhite via acmurthy)
  865. MAPREDUCE-1751. Change MapReduce to depend on Hadoop 'common' artifacts
  866. instead of 'core'. (tomwhite)
  867. MAPREDUCE-1535. Replace usage of FileStatus#isDir(). (Eli Collins via
  868. tomwhite)
  869. MAPREDUCE-1832. Allow file sizes less than 1MB in DFSIO benchmark. (shv)
  870. MAPREDUCE-1404. Move Cluster-Setup and Single-Node-Setup Docs from
  871. MapReduce to Common. (tomwhite)
  872. MAPREDUCE-1697. Document the behavior of -file option and deprecate it
  873. in favour of -files option in streaming. (Amareshwari Sriramadasu
  874. via vinodkv)
  875. MAPREDUCE-1033. Resolve location of scripts and configuration files after
  876. project split. (tomwhite)
  877. MAPREDUCE-1018. Document changes to the memory management and scheduling
  878. model. (Hemanth Yamijala via vinodkv)
  879. MAPREDUCE-1896. [Herriot] New property for multi user list. (Vinay Thota
  880. via cos)
  881. MAPREDUCE-1812. New properties for suspend and resume process. (Vinay
  882. Thota via cos)
  883. OPTIMIZATIONS
  884. MAPREDUCE-270. Fix the tasktracker to optionally send an out-of-band
  885. heartbeat on task-completion for better job-latency. (acmurthy)
  886. Configuration changes:
  887. add mapreduce.tasktracker.outofband.heartbeat
  888. MAPREDUCE-1186. Modified code in distributed cache to set permissions
  889. only on required set of localized paths.
  890. (Amareshwari Sriramadasu via yhemanth)
  891. MAPREDUCE-1501. FileInputFormat supports multi-level, recursive
  892. directory listing. (Zheng Shao via dhruba)
  893. MAPREDUCE-1556. upgrade to Avro 1.3.0. (cutting via tomwhite)
  894. MAPREDUCE-1613. Install/deploy source jars to Maven repo
  895. (Patrick Angeles via ddas)
  896. MAPREDUCE-1610. Forrest documentation should be updated to reflect
  897. the changes in MAPREDUCE-856. (Ravi Gummadi via vinodkv)
  898. MAPREDUCE-1853. Adds caching for TaskAttemptContext in MultipleOutputs.
  899. (Torsten Curdt via amareshwari)
  900. BUG FIXES
  901. MAPREDUCE-878. Rename fair scheduler design doc to
  902. fair-scheduler-design-doc.tex and add Apache license header (matei)
  903. HADOOP-4687. MapReduce is split from Hadoop Core. It is a subproject under
  904. Hadoop (Owen O'Malley)
  905. HADOOP-6096. Fix Eclipse project and classpath files following project
  906. split. (tomwhite)
  907. MAPREDUCE-419. Reconcile mapred.userlog.limit.kb defaults in configuration
  908. and code. (Philip Zeyliger via cdouglas)
  909. MAPREDUCE-2. Fixes a bug in KeyFieldBasedPartitioner in handling empty
  910. keys. (Amar Kamat via sharad)
  911. MAPREDUCE-130. Delete the jobconf copy from the log directory of the
  912. JobTracker when the job is retired. (Amar Kamat via sharad)
  913. MAPREDUCE-657. Fix hardcoded filesystem problem in CompletedJobStatusStore.
  914. (Amar Kamat via sharad)
  915. MAPREDUCE-179. Update progress in new RecordReaders. (cdouglas)
  916. MAPREDUCE-658. Replace NPE in distcp with a meaningful error message when
  917. the source path does not exist. (Ravi Gummadi via cdouglas)
  918. MAPREDUCE-671. Update ignore list to include untracked, generated
  919. build artifacts and config files. (cdouglas)
  920. MAPREDUCE-433. Use more reliable counters in TestReduceFetch. (cdouglas)
  921. MAPREDUCE-124. Fix a bug in failure handling of abort task of
  922. OutputCommiter. (Amareshwari Sriramadasu via sharad)
  923. MAPREDUCE-694. Fix to add jsp-api jars to capacity-scheduler classpath.
  924. (Giridharan Kesavan)
  925. MAPREDUCE-702. Fix eclipse-plugin jar target (Giridharan Kesavan)
  926. MAPREDUCE-522. Replace TestQueueCapacities with simpler test case to
  927. test integration between capacity scheduler and MR framework.
  928. (Sreekanth Ramakrishnan via yhemanth)
  929. MAPREDUCE-683. Fixes an initialization problem in the JobHistory.
  930. The initialization of JobHistoryFilesManager is now done in the
  931. JobHistory.init call. (Amar Kamat via ddas)
  932. MAPREDUCE-708. Fixes a bug to allow updating the reason for
  933. blacklisting a node on the JobTracker UI.
  934. (Sreekanth Ramakrishnan via yhemanth)
  935. MAPREDUCE-709. Fixes message displayed for a blacklisted node where
  936. the reason for blacklisting is due to the health check script
  937. timing out. (Sreekanth Ramakrishnan via yhemanth)
  938. MAPREDUCE-676. Existing diagnostic rules fail for MAP ONLY jobs.
  939. (Suhas Gogate via tomwhite)
  940. MAPREDUCE-722. Fixes a bug with tasktracker reservations for
  941. high memory jobs in capacity scheduler.
  942. (Vinod Kumar Vavilapalli via yhemanth)
  943. HADOOP-6090. Updates gridmix script to use new mapreduce api output
  944. format. (Amareshwari Sriramadasu via sharad)
  945. MAPREDUCE-732. Removed spurious log statements in the node
  946. blacklisting logic. (Sreekanth Ramakrishnan via yhemanth)
  947. MAPREDUCE-734. Fix a ConcurrentModificationException in unreserving
  948. unused reservations for a job when it completes.
  949. (Arun Murthy and Sreekanth Ramakrishnan via yhemanth)
  950. MAPREDUCE-733. Fix a RuntimeException while unreserving trackers
  951. that are blacklisted for a job.
  952. (Arun Murthy and Sreekanth Ramakrishnan via yhemanth)
  953. MAPREDUCE-677. Fix timeout in TestNodeRefresh. (Amar Kamat via
  954. sharad)
  955. MAPREDUCE-153. Fix timeout in TestJobInProgressListener. (Amar
  956. Kamat via sharad)
  957. MAPREDUCE-742. Fix output messages and java comments in the Pi related
  958. examples. (szetszwo)
  959. MAPREDUCE-565. Fix partitioner to work with new API. (Owen O'Malley via
  960. cdouglas)
  961. MAPREDUCE-680. Fix so MRUnit can handle reuse of Writable objects.
  962. (Aaron Kimball via johan)
  963. MAPREDUCE-18. Puts some checks for cross checking whether a reduce
  964. task gets the correct shuffle data. (Ravi Gummadi via ddas)
  965. MAPREDUCE-771. Fix scheduling of setup and cleanup tasks to use
  966. free slots instead of tasks for scheduling. (yhemanth)
  967. MAPREDUCE-717. Fixes some corner case issues in speculative
  968. execution heuristics. (Devaraj Das)
  969. MAPREDUCE-716. Make DBInputFormat work with Oracle. (Aaron Kimball
  970. via tomwhite)
  971. MAPREDUCE-735. Fixes a problem in the KeyFieldHelper to do with
  972. the end index for some inputs (Amar Kamat via ddas)
  973. MAPREDUCE-682. Removes reservations on tasktrackers which are
  974. blacklisted. (Sreekanth Ramakrishnan via yhemanth)
  975. MAPREDUCE-743. Fixes a problem to do with progress reporting
  976. in the map phase. (Ravi Gummadi via ddas)
  977. MAPREDUCE-765. Eliminate the deprecated warnings introduced by H-5438.
  978. (He Yongqiang via szetszwo)
  979. MAPREDUCE-383. Fix a bug in Pipes combiner due to bytes count not
  980. getting reset after the spill. (Christian Kunz via sharad)
  981. MAPREDUCE-809. Fix job-summary logs to correctly record status of FAILED
  982. and KILLED jobs. (acmurthy)
  983. MAPREDUCE-792. Fix unchecked warnings in DBInputFormat. (Aaron Kimball
  984. via szetszwo)
  985. MAPREDUCE-760. Fix a timing issue in TestNodeRefresh. (Amar Kamat via
  986. sharad)
  987. MAPREDUCE-40. Keep memory management backwards compatible for job
  988. configuration parameters and limits. (Rahul Kumar Singh via yhemanth)
  989. MAPREDUCE-587. Fixes a OOM issue in TestStreamingExitStatus.
  990. (Amar Kamat via ddas)
  991. MAPREDUCE-408. Fixes an assertion problem in TestKillSubProcesses
  992. (Ravi Gummadi via ddas)
  993. MAPREDUCE-659. Fix gridmix2 compilation. (Giridharan Kesavan)
  994. MAPREDUCE-796. Fixes a ClassCastException in an exception log in
  995. MultiThreadedMapRunner. (Amar Kamat via ddas)
  996. MAPREDUCE-808. Fixes a serialization problem in TypedBytes.
  997. (Klaas Bosteels via ddas)
  998. MAPREDUCE-845. Fix a findbugs heap size problem in build.xml and add
  999. a new property findbugs.heap.size. (Lee Tucker via szetszwo)
  1000. MAPREDUCE-838. Fixes a problem in the way commit of task outputs
  1001. happens. The bug was that even if commit failed, the task would
  1002. be declared as successful. (Amareshwari Sriramadasu via ddas)
  1003. MAPREDUCE-813. Updates Streaming and M/R tutorial documents.
  1004. (Corinne Chandel via ddas)
  1005. MAPREDUCE-805. Fixes some deadlocks in the JobTracker due to the fact
  1006. the JobTracker lock hierarchy wasn't maintained in some JobInProgress
  1007. method calls. (Amar Kamat via ddas)
  1008. MAPREDUCE-799. Fixes so all of the MRUnit self-tests run.
  1009. (Aaron Kimball via johan)
  1010. MAPREDUCE-848. Fixes a problem to do with TestCapacityScheduler
  1011. failing (Amar Kamat via ddas)
  1012. MAPREDUCE-840. DBInputFormat leaves open transaction.
  1013. (Aaron Kimball via tomwhite)
  1014. MAPREDUCE-859. Adds Avro and its dependencies required by Hadoop
  1015. common. (Ravi Gummadi via sharad)
  1016. MAPREDUCE-867. Fix ivy conf to look for avro jar from maven repo.
  1017. (Giridharan Kesavan)
  1018. MAPREDUCE-877. Added avro as a dependency to contrib ivy settings.
  1019. (Tsz Wo (Nicholas) Sze via yhemanth)
  1020. MAPREDUCE-852. In build.xml, remove the Main-Class, which is incorrectly
  1021. set in tools, and rename the target "tools-jar" to "tools". (szetszwo)
  1022. MAPREDUCE-773. Sends progress reports for compressed gzip inputs in maps.
  1023. Fixes a native direct buffer leak in LineRecordReader classes.
  1024. (Hong Tang and ddas)
  1025. MAPREDUCE-832. Reduce number of warning messages printed when
  1026. deprecated memory variables are used. (Rahul Kumar Singh via yhemanth)
  1027. MAPREDUCE-745. Fixes a testcase problem to do with generation of JobTracker
  1028. IDs. (Amar Kamat via ddas)
  1029. MAPREDUCE-834. Enables memory management on tasktrackers when old
  1030. memory management parameters are used in configuration.
  1031. (Sreekanth Ramakrishnan via yhemanth)
  1032. MAPREDUCE-818. Fixes Counters#getGroup API. (Amareshwari Sriramadasu
  1033. via sharad)
  1034. MAPREDUCE-807. Handles the AccessControlException during the deletion of
  1035. mapred.system.dir in the JobTracker. The JobTracker will bail out if it
  1036. encounters such an exception. (Amar Kamat via ddas)
  1037. MAPREDUCE-430. Fix a bug related to task getting stuck in case of
  1038. OOM error. (Amar Kamat via ddas)
  1039. MAPREDUCE-871. Fix ownership of Job/Task local files to have correct
  1040. group ownership according to the egid of the tasktracker.
  1041. (Vinod Kumar Vavilapalli via yhemanth)
  1042. MAPREDUCE-911. Fix a bug in TestTaskFail related to speculative
  1043. execution. (Amareshwari Sriramadasu via sharad)
  1044. MAPREDUCE-687. Fix an assertion in TestMiniMRMapRedDebugScript.
  1045. (Amareshwari Sriramadasu via sharad)
  1046. MAPREDUCE-924. Fixes the TestPipes testcase to use Tool.
  1047. (Amareshwari Sriramadasu via sharad)
  1048. MAPREDUCE-903. Add Avro jar to eclipse classpath.
  1049. (Philip Zeyliger via tomwhite)
  1050. MAPREDUCE-943. Removes a testcase in TestNodeRefresh that doesn't make
  1051. sense in the new Job recovery model. (Amar Kamat via ddas)
  1052. MAPREDUCE-764. TypedBytesInput's readRaw() does not preserve custom type
  1053. codes. (Klaas Bosteels via tomwhite)
  1054. HADOOP-6243. Fixes a NullPointerException in handling deprecated keys.
  1055. (Sreekanth Ramakrishnan via yhemanth)
  1056. MAPREDUCE-968. NPE in distcp encountered when placing _logs directory on
  1057. S3FileSystem. (Aaron Kimball via tomwhite)
  1058. MAPREDUCE-826. harchive doesn't use ToolRunner / harchive returns 0 even
  1059. if the job fails with exception (koji Noguchi via mahadev)
  1060. MAPREDUCE-839. unit test TestMiniMRChildTask fails on mac os-x (hong tang
  1061. via mahadev)
  1062. MAPREDUCE-112. Add counters for reduce input, output records to the new API.
  1063. (Jothi Padmanabhan via cdouglas)
  1064. MAPREDUCE-648. Fix two distcp bugs: (1) it should not launch a job if all
  1065. src paths are directories, and (2) it does not skip copying when updating
  1066. a single file. (Ravi Gummadi via szetszwo)
  1067. MAPREDUCE-946. Fix a regression in LineRecordReader where the
  1068. maxBytesToConsume parameter is not set correctly. (cdouglas)
  1069. MAPREDUCE-977. Missing jackson jars from Eclipse template. (tomwhite)
  1070. MAPREDUCE-988. Fix a packaging issue in the contrib modules. (Hong Tang via
  1071. cdouglas)
  1072. MAPREDUCE-971. distcp does not always remove distcp.tmp.dir. (Aaron Kimball
  1073. via tomwhite)
  1074. MAPREDUCE-995. Fix a bug in JobHistory where tasks completing after the job
  1075. is closed cause a NPE. (Jothi Padmanabhan via cdouglas)
  1076. MAPREDUCE-953. Fix QueueManager to dump queue configuration in JSON format.
  1077. (V.V. Chaitanya Krishna via yhemanth)
  1078. MAPREDUCE-645. Prevent distcp from running a job when the destination is a
  1079. file, but the source is not. (Ravi Gummadi via cdouglas)
  1080. MAPREDUCE-1002. Flushed writer in JobQueueClient so queue information is
  1081. printed correctly. (V.V. Chaitanya Krishna via yhemanth)
  1082. MAPREDUCE-1003. Fix compilation problem in eclipse plugin when
  1083. eclipse.home is set. (Ravi Gummadi via yhemanth)
  1084. MAPREDUCE-941. Vaidya script fails on Solaris. (Chad Metcalf
  1085. via tomwhite)
  1086. MAPREDUCE-912. Add and standardize Apache license headers. (Chad Metcalf
  1087. via cdouglas)
  1088. MAPREDUCE-1022. Fix compilation of vertica testcases. (Vinod Kumar
  1089. Vavilapalli via acmurthy)
  1090. MAPREDUCE-1000. Handle corrupt history files in JobHistory.initDone().
  1091. (Jothi Padmanabhan via sharad)
  1092. MAPREDUCE-1028. Fixed number of slots occupied by cleanup tasks to one
  1093. irrespective of slot size for the job.
  1094. (Ravi Gummadi via yhemanth)
  1095. MAPREDUCE-964. Fixed start and finish times of TaskStatus to be
  1096. consistent, thereby fixing inconsistencies in metering tasks.
  1097. (Sreekanth Ramakrishnan via yhemanth)
  1098. MAPREDUCE-1076. Deprecate ClusterStatus and add javadoc in ClusterMetrics.
  1099. (Amareshwari Sriramadasu via sharad)
  1100. MAPREDUCE-979. Fixed JobConf APIs related to memory parameters to return
  1101. values of new configuration variables when deprecated variables are
  1102. disabled. (Sreekanth Ramakrishnan via yhemanth)
  1103. MAPREDUCE-1030. Modified scheduling algorithm to return a map and reduce
  1104. task per heartbeat in the capacity scheduler.
  1105. (Rahul Kumar Singh via yhemanth)
  1106. MAPREDUCE-1071. Use DataInputStream rather than FSDataInputStream in the
  1107. JobHistory EventReader. (Hong Tang via cdouglas)
  1108. MAPREDUCE-986. Fix Rumen to work with truncated task lines. (Dick King via
  1109. cdouglas)
  1110. MAPREDUCE-1029. Fix failing TestCopyFiles by restoring the unzipping of
  1111. HDFS webapps from the hdfs jar. (Aaron Kimball and Jothi Padmanabhan via
  1112. cdouglas)
  1113. MAPREDUCE-769. Make findbugs and javac warnings to zero.
  1114. (Amareshwari Sriramadasu via sharad)
  1115. MAPREDUCE-1104. Initialize RecoveryManager in JobTracker cstr called by
  1116. Mumak. (Hong Tang via cdouglas)
  1117. MAPREDUCE-1061. Add unit test validating byte specifications for gridmix
  1118. jobs. (cdouglas)
  1119. MAPREDUCE-1077. Fix Rumen so that truncated tasks do not mark the job as
  1120. successful. (Dick King via cdouglas)
  1121. MAPREDUCE-1041. Make TaskInProgress::taskStatuses map package-private.
  1122. (Jothi Padmanabhan via cdouglas)
  1123. MAPREDUCE-1070. Prevent a deadlock in the fair scheduler servlet.
  1124. (Todd Lipcon via cdouglas)
  1125. MAPREDUCE-1086. Setup Hadoop logging environment for tasks to point to
  1126. task related parameters. (Ravi Gummadi via yhemanth)
  1127. MAPREDUCE-1105. Remove max limit configuration in capacity scheduler in
  1128. favor of max capacity percentage thus allowing the limit to go over
  1129. queue capacity. (Rahul Kumar Singh via yhemanth)
  1130. MAPREDUCE-1016. Make the job history log format JSON. (cutting)
  1131. MAPREDUCE-1038. Weave Mumak aspects only if related files have changed.
  1132. (Aaron Kimball via cdouglas)
  1133. MAPREDUCE-1163. Remove unused, hard-coded paths from libhdfs. (Allen
  1134. Wittenauer via cdouglas)
  1135. MAPREDUCE-962. Fix a NullPointerException while killing task process
  1136. trees. (Ravi Gummadi via yhemanth)
  1137. MAPREDUCE-1177. Correct setup/cleanup inversion in
  1138. JobTracker::getTaskReports. (Vinod Kumar Vavilapalli via cdouglas)
  1139. MAPREDUCE-1178. Fix ClassCastException in MultipleInputs by adding
  1140. a DelegatingRecordReader. (Amareshwari Sriramadasu and Jay Booth
  1141. via sharad)
  1142. MAPREDUCE-1068. Fix streaming job to show proper message if file is
  1143. is not present. (Amareshwari Sriramadasu via sharad)
  1144. MAPREDUCE-1147. Add map output counters to new API. (Amar Kamat via
  1145. cdouglas)
  1146. MAPREDUCE-915. The debug scripts are run as the job user. (ddas)
  1147. MAPREDUCE-1007. Fix NPE in CapacityTaskScheduler.getJobs().
  1148. (V.V.Chaitanya Krishna via sharad)
  1149. MAPREDUCE-28. Refactor TestQueueManager and fix default ACLs.
  1150. (V.V.Chaitanya Krishna and Rahul K Singh via sharad)
  1151. MAPREDUCE-1182. Fix overflow in reduce causing allocations to exceed the
  1152. configured threshold. (cdouglas)
  1153. MAPREDUCE-1239. Fix contrib components build dependencies.
  1154. (Giridharan Kesavan and omalley)
  1155. MAPREDUCE-787. Fix JobSubmitter to honor user given symlink path.
  1156. (Amareshwari Sriramadasu via sharad)
  1157. MAPREDUCE-1249. Update config default value for socket read timeout to
  1158. match code default. (Amareshwari Sriramadasu via cdouglas)
  1159. MAPREDUCE-1161. Remove ineffective synchronization in NotificationTestCase.
  1160. (Owen O'Malley via cdouglas)
  1161. MAPREDUCE-1244. Fix eclipse-plugin's build dependencies. (gkesavan)
  1162. MAPREDUCE-1075. Fix JobTracker to not throw an NPE for a non-existent
  1163. queue. (V.V.Chaitanya Krishna via yhemanth)
  1164. MAPREDUCE-754. Fix NPE in expiry thread when a TT is lost. (Amar Kamat
  1165. via sharad)
  1166. MAPREDUCE-1074. Document Reducer mark/reset functionality. (Jothi
  1167. Padmanabhan via cdouglas)
  1168. MAPREDUCE-1267. Fix typo in mapred-default.xml. (Todd Lipcon via cdouglas)
  1169. MAPREDUCE-952. Remove inadvertently reintroduced Task.Counter enum. (Jothi
  1170. Padmanabhan via cdouglas)
  1171. MAPREDUCE-1230. Fix handling of null records in VerticaInputFormat. (Omer
  1172. Trajman via cdouglas)
  1173. MAPREDUCE-1171. Allow shuffle retries and read-error reporting to be
  1174. configurable. (Amareshwari Sriramadasu via acmurthy)
  1175. MAPREDUCE-879. Fix broken unit test TestTaskTrackerLocalization on MacOS.
  1176. (Sreekanth Ramakrishnan via yhemanth)
  1177. MAPREDUCE-1124. Fix imprecise byte counts in Gridmix. (cdouglas)
  1178. MAPREDUCE-1222. Add an option to exclude numeric IP addresses in topologies
  1179. processed by Mumak. (Hong Tang via cdouglas)
  1180. MAPREDUCE-1284. Fix fts_open() call in task-controller that was failing
  1181. LinuxTaskController unit tests. (Ravi Gummadi via yhemanth)
  1182. MAPREDUCE-1143. Fix running task counters to be updated correctly
  1183. when speculative attempts are running for a TIP.
  1184. (Rahul Kumar Singh via yhemanth)
  1185. MAPREDUCE-1241. Use a default queue configuration in JobTracker when
  1186. mapred-queues.xml is unavailable. (Todd Lipcon via cdouglas)
  1187. MAPREDUCE-1301. Fix set up of permission checking script used in
  1188. localization tests. (Amareshwari Sriramadasu via yhemanth)
  1189. MAPREDUCE-1286. Remove quoting from client opts in TaskRunner. (Yuri
  1190. Pradkin via cdouglas)
  1191. MAPREDUCE-1059. Use distcp.bytes.per.map when adding sync markers in
  1192. distcp. (Aaron Kimball via cdouglas)
  1193. MAPREDUCE-1009. Update forrest documentation describing hierarchical
  1194. queues. (Vinod Kumar Vavilapalli via yhemanth)
  1195. MAPREDUCE-1342. Fixed deadlock in global blacklisting of tasktrackers.
  1196. (Amareshwari Sriramadasu via acmurthy)
  1197. MAPREDUCE-1316. Fixes a memory leak of TaskInProgress instances in
  1198. the jobtracker. (Amar Kamat via yhemanth)
  1199. MAPREDUCE-1359. TypedBytes TestIO doesn't mkdir its test dir first.
  1200. (Anatoli Fomenko via cos)
  1201. MAPREDUCE-1314. Correct errant mapreduce.x.mapreduce.x replacements from
  1202. bulk change. (Amareshwari Sriramadasu via cdouglas)
  1203. MAPREDUCE-1365. Restore accidentally renamed test in
  1204. TestTaskTrackerBloacklisting. (Amareshwari Sriramadasu via cdouglas)
  1205. MAPREDUCE-1406. Fix spelling of JobContext.MAP_COMBINE_MIN_SPILLS.
  1206. (cdouglas)
  1207. MAPREDUCE-1369. JUnit tests should never depend on anything in conf
  1208. (Anatoli Fomenko via cos)
  1209. MAPREDUCE-1412. Fix timer granularity issue causing failures in
  1210. TestTaskTrackerBlacklisting. (cdouglas)
  1211. MAPREDUCE-1448. Respect --config option in Mumak script. (Hong Tang via
  1212. cdouglas)
  1213. MAPREDUCE-1251. c++ utils doesn't compile. (Eli Collins via tomwhite)
  1214. MAPREDUCE-1522. FileInputFormat may use the default FileSystem for the
  1215. input path. (Tsz Wo (Nicholas), SZE via cdouglas)
  1216. MAPREDUCE-1407. Update javadoc in mapreduce.{Mapper,Reducer} to match
  1217. actual usage. (Benoit Sigoure via cdouglas)
  1218. MAPREDUCE-1258. Fix fair scheduler event log not logging job info.
  1219. (matei)
  1220. MAPREDUCE-1089. Fix NPE in fair scheduler preemption when tasks are
  1221. scheduled but not running. (Todd Lipcon via matei)
  1222. MAPREDUCE-1014. Fix the libraries for common and hdfs. (omalley)
  1223. MAPREDUCE-1111. JT Jetty UI not working if we run mumak.sh
  1224. off packaged distribution directory. (hong tang via mahadev)
  1225. MAPREDUCE-1133. Eclipse .classpath template has outdated jar files and is
  1226. missing some new ones. (cos)
  1227. MAPREDUCE-1098. Fixed the distributed-cache to not do i/o while holding a
  1228. global lock. (Amareshwari Sriramadasu via acmurthy)
  1229. MAPREDUCE-1158. Fix JT running maps and running reduces metrics.
  1230. (sharad)
  1231. MAPREDUCE-1160. Reduce verbosity of log lines in some Map/Reduce classes
  1232. to avoid filling up jobtracker logs on a busy cluster.
  1233. (Ravi Gummadi and Hong Tang via yhemanth)
  1234. MAPREDUCE-1153. Fix tasktracker metrics when trackers are decommissioned.
  1235. (sharad)
  1236. MAPREDUCE-1128. Fix MRUnit to prohibit iterating over values twice. (Aaron
  1237. Kimball via cdouglas)
  1238. MAPREDUCE-665. Move libhdfs to HDFS subproject. (Eli Collins via dhruba)
  1239. MAPREDUCE-1196. Fix FileOutputCommitter to use the deprecated cleanupJob
  1240. api correctly. (acmurthy)
  1241. MAPREDUCE-1244. Fix eclipse-plugin's build dependencies. (gkesavan)
  1242. MAPREDUCE-1140. Fix DistributedCache to not decrement reference counts for
  1243. unreferenced files in error conditions.
  1244. (Amareshwari Sriramadasu via yhemanth)
  1245. MAPREDUCE-1245. Fix TestFairScheduler failures by instantiating lightweight
  1246. Jobtracker. (sharad)
  1247. MAPREDUCE-1260. Update Eclipse configuration to match changes to Ivy
  1248. configuration. (Edwin Chan via cos)
  1249. MAPREDUCE-1152. Distinguish between failed and killed tasks in
  1250. JobTrackerInstrumentation. (Sharad Agarwal via cdouglas)
  1251. MAPREDUCE-1285. In DistCp.deleteNonexisting(..), get class from the
  1252. parameter instead of using FileStatus.class. (Peter Romianowski via
  1253. szetszwo)
  1254. MAPREDUCE-1294. Build fails to pull latest hadoop-core-* artifacts (cos)
  1255. MAPREDUCE-1213. TaskTrackers restart is faster because it deletes
  1256. distributed cache directory asynchronously. (Zheng Shao via dhruba)
  1257. MAPREDUCE-1265. The task attempt error log prints the name of the
  1258. tasktracker machine. (Scott Chen via dhruba)
  1259. MAPREDUCE-1201. ProcfsBasedProcessTree collects CPU usage information.
  1260. (Scott Chen via dhruba)
  1261. MAPREDUCE-1326. fi tests don't use fi-site.xml (cos)
  1262. MAPREDUCE-1165. Replace non-portable function name with C99 equivalent.
  1263. (Allen Wittenauer via cdouglas)
  1264. MAPREDUCE-1331. Fixes a typo in a testcase (Devaraj Das)
  1265. MAPREDUCE-1293. AutoInputFormat doesn't work with non-default FileSystems.
  1266. (Andrew Hitchcock via tomwhite)
  1267. MAPREDUCE-1131. Using profilers other than hprof can cause JobClient to
  1268. report job failure. (Aaron Kimball via tomwhite)
  1269. MAPREDUCE-1155. Streaming tests swallow exceptions.
  1270. (Todd Lipcon via tomwhite)
  1271. MAPREDUCE-1212. Mapreduce contrib project ivy dependencies are not included
  1272. in binary target. (Aaron Kimball via tomwhite)
  1273. MAPREDUCE-1388. Move the HDFS RAID package from HDFS to MAPREDUCE.
  1274. (Eli Collins via dhruba)
  1275. MAPREDUCE-1322. Defines default value for staging directory to be user
  1276. based fixing a failing streaming test.
  1277. (Devaraj Das and Amareshwari Sriramadasu via yhemanth)
  1278. MAPREDUCE-899. Modified LinuxTaskController to check that task-controller
  1279. has right permissions and ownership before performing any actions.
  1280. (Amareshwari Sriramadasu via yhemanth)
  1281. MAPREDUCE-1443. DBInputFormat can leak connections.
  1282. (Aaron Kimball via tomwhite)
  1283. MAPREDUCE-1457. Fixes JobTracker to get the FileSystem object within
  1284. getStagingAreaDir within a privileged block. Fixes Child.java to use the
  1285. appropriate UGIs while getting the TaskUmbilicalProtocol proxy and
  1286. while executing the task. (Jakob Homan via ddas)
  1287. MAPREDUCE-1399. The archive command shows a null error message (nicholas
  1288. via mahadev)
  1289. MAPREDUCE-1305. Improve efficiency of distcp -delete. (Peter Romianowski
  1290. via cdouglas)
  1291. MAPREDUCE-1474. Update forrest documentation for Hadoop Archives. (Mahadev
  1292. Konar via cdouglas)
  1293. MAPREDUCE-1400. Use tr rather than sed to effect literal substitution in
  1294. the build script. (Allen Wittenauer via cdouglas)
  1295. MAPREDUCE-1358. Avoid false positives in OutputLogFilter. (Todd Lipcon via
  1296. cdouglas)
  1297. MAPREDUCE-1490. Fix a NullPointerException that could occur during
  1298. instantiation and initialization of the DistributedRaidFileSystem.
  1299. (Rodrigo Schmidt via dhruba)
  1300. MAPREDUCE-1476. Fix the M/R framework to not call commit for special
  1301. tasks like job setup/cleanup and task cleanup.
  1302. (Amareshwari Sriramadasu via yhemanth)
  1303. MAPREDUCE-1398. Fix TaskLauncher to stop waiting for slots on a TIP that
  1304. is killed / failed.
  1305. (Amareshwari Sriramadasu via yhemanth)
  1306. MAPREDUCE-1491. The parity files created by the RAID are combined
  1307. using Hadoop Archive Files (HAR). (Rodrigo Schmidt via dhruba)
  1308. MAPREDUCE-1378. URL encode link in jobhistory.jsp to avoid errors caused by
  1309. unescaped characters. (E. Sammer via cdouglas)
  1310. MAPREDUCE-1519. RaidNode fails to create new parity file
  1311. if an older version already exists. (Rodrigo Schmidt via dhruba)
  1312. MAPREDUCE-1537. Fixes a compilation problem in a testcase after commit
  1313. HDFS-984. (Jitendra Nath Pandey via ddas)
  1314. MAPREDUCE-1537. The patch makes the job client call the getDelegationToken
  1315. only when security is enabled. (Jitendra Nath Pandey via ddas)
  1316. MAPREDUCE-1510. RAID should regenerate parity files if they get deleted.
  1317. (Rodrigo Schmidt via dhruba)
  1318. MAPREDUCE-1421. Fix the LinuxTaskController tests failing on trunk after
  1319. the commit of MAPREDUCE-1385. (Amareshwari Sriramadasu via vinodkv)
  1320. MAPREDUCE-1520. Fix TestMiniMRLocalFS failure caused by regression in
  1321. getting user working dir. (Amareshwari Sriramadasu via cdouglas)
  1322. MAPREDUCE-1512. RAID uses HarFileSystem directly instead of
  1323. FileSystem.get (Rodrigo Schmidt via dhruba)
  1324. MAPREDUCE-1435. Fix symlink handling in task work directory when
  1325. cleaning up, essentially to avoid following links.
  1326. (Ravi Gummadi via yhemanth)
  1327. MAPREDUCE-1518. RaidNode does not run the deletion check on the
  1328. directory that stores the parity files. (Rodrigo Schmidt via dhruba)
  1329. MAPREDUCE-1573. TestStreamingAsDifferentUser fails if run as tt_user.
  1330. (Ravi Gummadi via vinodkv)
  1331. MAPREDUCE-927. Cleanup of task-logs should happen in TaskTracker instead
  1332. of the Child. (Amareshwari Sriramadasu via vinodkv)
  1333. MAPREDUCE-1578. Decouple HadoopArchives vesrion from HarFileSystem version.
  1334. (Rodrigo Schmidt via szetszwo)
  1335. MAPREDUCE-1422. Fix cleanup of localized job directory to work if files
  1336. with non-deletable permissions are created within it.
  1337. (Amar Kamat via yhemanth)
  1338. MAPREDUCE-1306. Randomize the arrival of heartbeat responses in Mumak.
  1339. (Tamas Sarlos via cdouglas)
  1340. MAPREDUCE-1579. archive: check and possibly replace the space charater
  1341. in source paths. (szetszwo)
  1342. MAPREDUCE-1536. DataDrivenDBInputFormat does not split date columns correctly.
  1343. (Aaron Kimball via enis)
  1344. MAPREDUCE-890. After HADOOP-4491, the user who started mapred system is
  1345. not able to run job. (Ravi Gummadi via vinodkv)
  1346. MAPREDUCE-1615. Fix compilation of TestSubmitJob. (cdouglas)
  1347. MAPREDUCE-1508. Protect against NPE in TestMultipleLevelCaching. (Aaron
  1348. Kimball via cdouglas)
  1349. MAPREDUCE-1497. Suppress spurious findbugs warning about IndexCache
  1350. synchronization. (Amareshwari Sriramadasu via cdouglas)
  1351. MAPREDUCE-1420. Fix TestTTResourceReporting failure. (Scott Chen via
  1352. cdouglas)
  1353. MAPREDUCE-1480. Correctly initialize child RecordReaders in
  1354. CombineFileInputFormat. (Aaron Kimball via cdouglas)
  1355. MAPREDUCE-1348. Fix block forensics packaging. (Tom White via cdouglas)
  1356. MAPREDUCE-1628. HarFileSystem shows incorrect replication numbers and
  1357. permissions. (szetszwo via mahadev)
  1358. MAPREDUCE-1602. Fix the error message for the case that src does not
  1359. exist. (szetszwo)
  1360. MAPREDUCE-1585. Create Hadoop Archives version 2 with filenames
  1361. URL-encoded (rodrigo via mahadev)
  1362. MAPREDUCE-1523. Sometimes rumen trace generator fails to extract the job
  1363. finish time. (dick king via mahadev)
  1364. MAPREDUCE-1635. ResourceEstimator does not work after MAPREDUCE-842.
  1365. (Amareshwari Sriramadasu via vinodkv)
  1366. MAPREDUCE-889. binary communication formats added to Streaming by
  1367. HADOOP-1722 should be documented. (Klaas Bosteels via tomwhite)
  1368. MAPREDUCE-1031. ant tar target doens't seem to compile tests in contrib
  1369. projects. (Aaron Kimball via tomwhite)
  1370. MAPREDUCE-1692. Removed unused testcase TestStreamedMerge.
  1371. (Sreekanth Ramakrishnan and Amareshwari Sriramadasu via yhemanth)
  1372. MAPREDUCE-1062. Fix ReliabilityTest to work with retired jobs. (Sreekanth
  1373. Ramakrishnan via cdouglas)
  1374. MAPREDUCE-1409. IOExceptions thrown from FIleOutputCommitter::abortTask
  1375. should cause the task to fail. (Amareshwari Sriramadasu via cdouglas)
  1376. MAPREDUCE-1695. Include capacity scheduler in findbugs and javadoc-dev
  1377. targets and also fix existing warnings. (Hong Tang via yhemanth)
  1378. MAPREDUCE-1494. Ensure TestJobDirCleanup verifies the correct paths.
  1379. (Amareshwari Sriramadasu via cdouglas)
  1380. MAPREDUCE-1622. Include missing slf4j dependencies. (cdouglas)
  1381. MAPREDUCE-1515. Accept java5.home from build.properties, not only from the
  1382. command line when building forrest docs. (Al Thompson via cdouglas)
  1383. MAPREDUCE-1618. Add missing javadoc to JobStatus::*JobAcls. (Amareshwari
  1384. Sriramadasu via cdouglas)
  1385. MAPREDUCE-1219. Remove job level metrics from jobtracker metrics to ease
  1386. undue load on jobtracker. (Sreekanth Ramakrishnan via sharad)
  1387. MAPREDUCE-1604. Add Forrest documentation for Job ACLs.
  1388. (Amareshwari Sriramadasu via yhemanth)
  1389. MAPREDUCE-1705. Archiving and Purging of HDFS parity files should
  1390. handle globbed policies accurately. (Rodrigo Schmidt via dhruba)
  1391. MAPREDUCE-1612. job conf file is not accessible from job history web page.
  1392. (Ravi Gummadi and Sreekanth Ramakrishnan via vinodkv)
  1393. MAPREDUCE-1397. NullPointerException observed during task failures.
  1394. (Amareshwari Sriramadasu via vinodkv)
  1395. MAPREDUCE-1728. Oracle timezone strings do not match Java.
  1396. (Aaron Kimball via tomwhite)
  1397. MAPREDUCE-1609. TaskTracker.localizeJob should not set permissions on
  1398. job log directory recursively. (Amareshwari Sriramadasu via vinodkv)
  1399. MAPREDUCE-1657. After task logs directory is deleted, tasklog servlet
  1400. displays wrong error message about job ACLs. (Ravi Gummadi via vinodkv)
  1401. MAPREDUCE-1727. TestJobACLs fails after HADOOP-6686. (Ravi Gummadi via vinodkv)
  1402. MAPREDUCE-1611. Refresh nodes and refresh queues doesnt work with service
  1403. authorization enabled. (Amar Kamat via vinodkv)
  1404. MAPREDUCE-1276. Correct flaws in the shuffle related to connection setup
  1405. and failure attribution. (Amareshwari Sriramadasu via cdouglas)
  1406. MAPREDUCE-1372. ConcurrentModificationException in JobInProgress.
  1407. (Dick King and Amareshwari Sriramadasu via tomwhite)
  1408. MAPREDUCE-118. Fix Job.getJobID(). (Amareshwari Sriramadasu via sharad)
  1409. MAPREDUCE-913. TaskRunner crashes with NPE resulting in held up slots,
  1410. UNINITIALIZED tasks and hung TaskTracker. (Amareshwari Sriramadasu and
  1411. Sreekanth Ramakrishnan via vinodkv)
  1412. MAPREDUCE-1725. Fix MapReduce API incompatibilities between 0.20 and 0.21.
  1413. (tomwhite)
  1414. MAPREDUCE-1606. TestJobACLs may timeout as there are no slots for launching
  1415. JOB_CLEANUP task. (Ravi Gummadi via vinodkv)
  1416. MAPREDUCE-1765. Correct streaming documentation for StreamXmlRecordReader.
  1417. (Corinne Chandel via amareshwari)
  1418. MAPREDUCE-1880. Fix BigDecimal.divide(..) in the pi example. (szetszwo)
  1419. MAPREDUCE-1885. Revert FileSystem create method that takes CreateFlags
  1420. (MapReduce part of HADOOP-6826). (Ravi Gummadi via tomwhite)
  1421. MAPREDUCE-1870. Harmonize MapReduce JAR library versions with Common and
  1422. HDFS. (tomwhite)
  1423. MAPREDUCE-1791. Remote cluster control functionality needs JavaDocs
  1424. improvement (Konstantin Boudnik)
  1425. MAPREDUCE-1942. 'compile-fault-inject' should never be called directly.
  1426. (Konstantin Boudnik)
  1427. MAPREDUCE-1876. Fixes TaskAttemptStartedEvent to correctly log event type
  1428. for all task types. (Amar Kamat via amareshwari)
  1429. MAPREDUCE-1926. MapReduce distribution is missing build-utils.xml.
  1430. (tomwhite)
  1431. MAPREDUCE-2012. Some contrib tests fail in branch 0.21 and trunk.
  1432. (Amareshwari Sriramadasu via tomwhite)
  1433. MAPREDUCE-1980. Fixes TaskAttemptUnsuccessfulCompletionEvent and
  1434. TaskAttemptFinishedEvent to correctly log event type for all task types.
  1435. (Amar Kamat via amareshwari)
  1436. MAPREDUCE-1856. Extract a subset of tests for smoke (DOA) validation (cos)