CHANGES.txt 24 KB

123456789101112131415161718192021222324252627282930313233343536373839404142434445464748495051525354555657585960616263646566676869707172737475767778798081828384858687888990919293949596979899100101102103104105106107108109110111112113114115116117118119120121122123124125126127128129130131132133134135136137138139140141142143144145146147148149150151152153154155156157158159160161162163164165166167168169170171172173174175176177178179180181182183184185186187188189190191192193194195196197198199200201202203204205206207208209210211212213214215216217218219220221222223224225226227228229230231232233234235236237238239240241242243244245246247248249250251252253254255256257258259260261262263264265266267268269270271272273274275276277278279280281282283284285286287288289290291292293294295296297298299300301302303304305306307308309310311312313314315316317318319320321322323324325326327328329330331332333334335336337338339340341342343344345346347348349350351352353354355356357358359360361362363364365366367368369370371372373374375376377378379380381382383384385386387388389390391392393394395396397398399400401402403404405406407408409410411412413414415416417418419420421422423424425426427428429430431432433434
  1. HBase Change Log
  2. Release 0.16.0 - 2008-02-04
  3. INCOMPATIBLE CHANGES
  4. HADOOP-2056 A table with row keys containing colon fails to split regions
  5. HADOOP-2079 Fix generated HLog, HRegion names
  6. HADOOP-2495 Minor performance improvements: Slim-down BatchOperation, etc.
  7. HADOOP-2506 Remove the algebra package
  8. HADOOP-2519 Performance improvements: Customized RPC serialization
  9. HADOOP-2478 Restructure how HBase lays out files in the file system (phase 1)
  10. (test input data)
  11. HADOOP-2478 Restructure how HBase lays out files in the file system (phase 2)
  12. Includes migration tool org.apache.hadoop.hbase.util.Migrate
  13. HADOOP-2558 org.onelab.filter.BloomFilter class uses 8X the memory it should
  14. be using
  15. NEW FEATURES
  16. HADOOP-2061 Add new Base64 dialects
  17. HADOOP-2084 Add a LocalHBaseCluster
  18. HADOOP-2068 RESTful interface (Bryan Duxbury via Stack)
  19. HADOOP-2316 Run REST servlet outside of master
  20. (Bryan Duxbury & Stack)
  21. HADOOP-1550 No means of deleting a'row' (Bryan Duxbuery via Stack)
  22. HADOOP-2384 Delete all members of a column family on a specific row
  23. (Bryan Duxbury via Stack)
  24. HADOOP-2395 Implement "ALTER TABLE ... CHANGE column" operation
  25. (Bryan Duxbury via Stack)
  26. HADOOP-2240 Truncate for hbase (Edward Yoon via Stack)
  27. HADOOP-2389 Provide multiple language bindings for HBase (Thrift)
  28. (David Simpson via Stack)
  29. OPTIMIZATIONS
  30. HADOOP-2479 Save on number of Text object creations
  31. HADOOP-2485 Make mapfile index interval configurable (Set default to 32
  32. instead of 128)
  33. HADOOP-2553 Don't make Long objects calculating hbase type hash codes
  34. HADOOP-2377 Holding open MapFile.Readers is expensive, so use less of them
  35. HADOOP-2407 Keeping MapFile.Reader open is expensive: Part 2
  36. HADOOP-2533 Performance: Scanning, just creating MapWritable in next
  37. consumes >20% CPU
  38. HADOOP-2443 Keep lazy cache of regions in client rather than an
  39. 'authoritative' list (Bryan Duxbury via Stack)
  40. HADOOP-2600 Performance: HStore.getRowKeyAtOrBefore should use
  41. MapFile.Reader#getClosest (before)
  42. (Bryan Duxbury via Stack)
  43. BUG FIXES
  44. HADOOP-2059 In tests, exceptions in min dfs shutdown should not fail test
  45. (e.g. nightly #272)
  46. HADOOP-2064 TestSplit assertion and NPE failures (Patch build #952 and #953)
  47. HADOOP-2124 Use of `hostname` does not work on Cygwin in some cases
  48. HADOOP-2083 TestTableIndex failed in #970 and #956
  49. HADOOP-2109 Fixed race condition in processing server lease timeout.
  50. HADOOP-2137 hql.jsp : The character 0x19 is not valid
  51. HADOOP-2109 Fix another race condition in processing dead servers,
  52. Fix error online meta regions: was using region name and not
  53. startKey as key for map.put. Change TestRegionServerExit to
  54. always kill the region server for the META region. This makes
  55. the test more deterministic and getting META reassigned was
  56. problematic.
  57. HADOOP-2155 Method expecting HBaseConfiguration throws NPE when given Configuration
  58. HADOOP-2156 BufferUnderflowException for un-named HTableDescriptors
  59. HADOOP-2161 getRow() is orders of magnitudes slower than get(), even on rows
  60. with one column (Clint Morgan and Stack)
  61. HADOOP-2040 Hudson hangs AFTER test has finished
  62. HADOOP-2274 Excess synchronization introduced by HADOOP-2139 negatively
  63. impacts performance
  64. HADOOP-2196 Fix how hbase sits in hadoop 'package' product
  65. HADOOP-2276 Address regression caused by HADOOP-2274, fix HADOOP-2173 (When
  66. the master times out a region servers lease, the region server
  67. may not restart)
  68. HADOOP-2253 getRow can return HBASE::DELETEVAL cells
  69. (Bryan Duxbury via Stack)
  70. HADOOP-2295 Fix assigning a region to multiple servers
  71. HADOOP-2234 TableInputFormat erroneously aggregates map values
  72. HADOOP-2308 null regioninfo breaks meta scanner
  73. HADOOP-2304 Abbreviated symbol parsing error of dir path in jar command
  74. (Edward Yoon via Stack)
  75. HADOOP-2320 Committed TestGet2 is managled (breaks build).
  76. HADOOP-2322 getRow(row, TS) client interface not properly connected
  77. HADOOP-2309 ConcurrentModificationException doing get of all region start keys
  78. HADOOP-2321 TestScanner2 does not release resources which sometimes cause the
  79. test to time out
  80. HADOOP-2315 REST servlet doesn't treat / characters in row key correctly
  81. (Bryan Duxbury via Stack)
  82. HADOOP-2332 Meta table data selection in Hbase Shell
  83. (Edward Yoon via Stack)
  84. HADOOP-2347 REST servlet not thread safe but run in a threaded manner
  85. (Bryan Duxbury via Stack)
  86. HADOOP-2365 Result of HashFunction.hash() contains all identical values
  87. HADOOP-2362 Leaking hdfs file handle on region split
  88. HADOOP-2338 Fix NullPointerException in master server.
  89. HADOOP-2380 REST servlet throws NPE when any value node has an empty string
  90. (Bryan Duxbury via Stack)
  91. HADOOP-2350 Scanner api returns null row names, or skips row names if
  92. different column families do not have entries for some rows
  93. HADOOP-2283 AlreadyBeingCreatedException (Was: Stuck replay of failed
  94. regionserver edits)
  95. HADOOP-2392 TestRegionServerExit has new failure mode since HADOOP-2338
  96. HADOOP-2324 Fix assertion failures in TestTableMapReduce
  97. HADOOP-2396 NPE in HMaster.cancelLease
  98. HADOOP-2397 The only time that a meta scanner should try to recover a log is
  99. when the master is starting
  100. HADOOP-2417 Fix critical shutdown problem introduced by HADOOP-2338
  101. HADOOP-2418 Fix assertion failures in TestTableMapReduce, TestTableIndex,
  102. and TestTableJoinMapReduce
  103. HADOOP-2414 Fix ArrayIndexOutOfBoundsException in bloom filters.
  104. HADOOP-2430 Master will not shut down if there are no active region servers
  105. HADOOP-2199 Add tools for going from hregion filename to region name in logs
  106. HADOOP-2441 Fix build failures in TestHBaseCluster
  107. HADOOP-2451 End key is incorrectly assigned in many region splits
  108. HADOOP-2455 Error in Help-string of CREATE command (Edward Yoon via Stack)
  109. HADOOP-2465 When split parent regions are cleaned up, not all the columns are
  110. deleted
  111. HADOOP-2468 TestRegionServerExit failed in Hadoop-Nightly #338
  112. HADOOP-2467 scanner truncates resultset when > 1 column families
  113. HADOOP-2503 REST Insert / Select encoding issue (Bryan Duxbury via Stack)
  114. HADOOP-2505 formatter classes missing apache license
  115. HADOOP-2504 REST servlet method for deleting a scanner was not properly
  116. mapped (Bryan Duxbury via Stack)
  117. HADOOP-2507 REST servlet does not properly base64 row keys and column names
  118. (Bryan Duxbury via Stack)
  119. HADOOP-2530 Missing type in new hbase custom RPC serializer
  120. HADOOP-2490 Failure in nightly #346 (Added debugging of hudson failures).
  121. HADOOP-2558 fixes for build up on hudson (part 1, part 2, part 3, part 4)
  122. HADOOP-2500 Unreadable region kills region servers
  123. HADOOP-2579 Initializing a new HTable object against a nonexistent table
  124. throws a NoServerForRegionException instead of a
  125. TableNotFoundException when a different table has been created
  126. previously (Bryan Duxbury via Stack)
  127. HADOOP-2587 Splits blocked by compactions cause region to be offline for
  128. duration of compaction.
  129. HADOOP-2592 Scanning, a region can let out a row that its not supposed
  130. to have
  131. HADOOP-2493 hbase will split on row when the start and end row is the
  132. same cause data loss (Bryan Duxbury via Stack)
  133. HADOOP-2629 Shell digests garbage without complaint
  134. HADOOP-2619 Compaction errors after a region splits
  135. HADOOP-2621 Memcache flush flushing every 60 secs with out considering
  136. the max memcache size
  137. HADOOP-2584 Web UI displays an IOException instead of the Tables
  138. HADOOP-2650 Remove Writables.clone and use WritableUtils.clone from
  139. hadoop instead
  140. HADOOP-2668 Documentation and improved logging so fact that hbase now
  141. requires migration comes as less of a surprise
  142. HADOOP-2686 Removed tables stick around in .META.
  143. HADOOP-2688 IllegalArgumentException processing a shutdown stops
  144. server going down and results in millions of lines of output
  145. HADOOP-2706 HBase Shell crash
  146. HADOOP-2712 under load, regions won't split
  147. HADOOP-2675 Options not passed to rest/thrift
  148. HADOOP-2722 Prevent unintentional thread exit in region server and master
  149. HADOOP-2718 Copy Constructor HBaseConfiguration(Configuration) will override
  150. hbase configurations if argumant is not an instance of
  151. HBaseConfiguration.
  152. HADOOP-2753 Back out 2718; programmatic config works but hbase*xml conf
  153. is overridden
  154. HADOOP-2718 Copy Constructor HBaseConfiguration(Configuration) will override
  155. hbase configurations if argumant is not an instance of
  156. HBaseConfiguration (Put it back again).
  157. HADOOP-2631 2443 breaks HTable.getStartKeys when there is more than one
  158. table or table you are enumerating isn't the first table
  159. Delete empty file: src/contrib/hbase/src/java/org/apache/hadoop/hbase/mapred/
  160. TableOutputCollector.java per Nigel Daley
  161. HADOOP-2731 Under load, regions become extremely large and eventually cause
  162. region servers to become unresponsive
  163. HADOOP-2773 Master marks region offline when it is recovering from a region
  164. server death
  165. IMPROVEMENTS
  166. HADOOP-2401 Add convenience put method that takes writable
  167. (Johan Oskarsson via Stack)
  168. HADOOP-2074 Simple switch to enable DEBUG level-logging in hbase
  169. HADOOP-2088 Make hbase runnable in $HADOOP_HOME/build(/contrib/hbase)
  170. HADOOP-2126 Use Bob Jenkins' hash for bloom filters
  171. HADOOP-2157 Make Scanners implement Iterable
  172. HADOOP-2176 Htable.deleteAll documentation is ambiguous
  173. HADOOP-2139 (phase 1) Increase parallelism in region servers.
  174. HADOOP-2267 [Hbase Shell] Change the prompt's title from 'hbase' to 'hql'.
  175. (Edward Yoon via Stack)
  176. HADOOP-2139 (phase 2) Make region server more event driven
  177. HADOOP-2289 Useless efforts of looking for the non-existant table in select
  178. command.
  179. (Edward Yoon via Stack)
  180. HADOOP-2257 Show a total of all requests and regions on the web ui
  181. (Paul Saab via Stack)
  182. HADOOP-2261 HTable.abort no longer throws exception if there is no active update.
  183. HADOOP-2287 Make hbase unit tests take less time to complete.
  184. HADOOP-2262 Retry n times instead of n**2 times.
  185. HADOOP-1608 Relational Algrebra Operators
  186. (Edward Yoon via Stack)
  187. HADOOP-2198 HTable should have method to return table metadata
  188. HADOOP-2296 hbase shell: phantom columns show up from select command
  189. HADOOP-2297 System.exit() Handling in hbase shell jar command
  190. (Edward Yoon via Stack)
  191. HADOOP-2224 Add HTable.getRow(ROW, ts)
  192. (Bryan Duxbury via Stack)
  193. HADOOP-2339 Delete command with no WHERE clause
  194. (Edward Yoon via Stack)
  195. HADOOP-2299 Support inclusive scans (Bryan Duxbury via Stack)
  196. HADOOP-2333 Client side retries happen at the wrong level
  197. HADOOP-2357 Compaction cleanup; less deleting + prevent possible file leaks
  198. HADOOP-2392 TestRegionServerExit has new failure mode since HADOOP-2338
  199. HADOOP-2370 Allow column families with an unlimited number of versions
  200. (Edward Yoon via Stack)
  201. HADOOP-2047 Add an '--master=X' and '--html' command-line parameters to shell
  202. (Edward Yoon via Stack)
  203. HADOOP-2351 If select command returns no result, it doesn't need to show the
  204. header information (Edward Yoon via Stack)
  205. HADOOP-2285 Add being able to shutdown regionservers (Dennis Kubes via Stack)
  206. HADOOP-2458 HStoreFile.writeSplitInfo should just call
  207. HStoreFile.Reference.write
  208. HADOOP-2471 Add reading/writing MapFile to PerformanceEvaluation suite
  209. HADOOP-2522 Separate MapFile benchmark from PerformanceEvaluation
  210. (Tom White via Stack)
  211. HADOOP-2502 Insert/Select timestamp, Timestamp data type in HQL
  212. (Edward Yoon via Stack)
  213. HADOOP-2450 Show version (and svn revision) in hbase web ui
  214. HADOOP-2472 Range selection using filter (Edward Yoon via Stack)
  215. HADOOP-2548 Make TableMap and TableReduce generic
  216. (Frederik Hedberg via Stack)
  217. HADOOP-2557 Shell count function (Edward Yoon via Stack)
  218. HADOOP-2589 Change an classes/package name from Shell to hql
  219. (Edward Yoon via Stack)
  220. HADOOP-2545 hbase rest server should be started with hbase-daemon.sh
  221. HADOOP-2525 Same 2 lines repeated 11 million times in HMaster log upon
  222. HMaster shutdown
  223. HADOOP-2616 hbase not spliting when the total size of region reaches max
  224. region size * 1.5
  225. HADOOP-2643 Make migration tool smarter.
  226. Release 0.15.1
  227. Branch 0.15
  228. INCOMPATIBLE CHANGES
  229. HADOOP-1931 Hbase scripts take --ARG=ARG_VALUE when should be like hadoop
  230. and do ---ARG ARG_VALUE
  231. NEW FEATURES
  232. HADOOP-1768 FS command using Hadoop FsShell operations
  233. (Edward Yoon via Stack)
  234. HADOOP-1784 Delete: Fix scanners and gets so they work properly in presence
  235. of deletes. Added a deleteAll to remove all cells equal to or
  236. older than passed timestamp. Fixed compaction so deleted cells
  237. do not make it out into compacted output. Ensure also that
  238. versions > column max are dropped compacting.
  239. HADOOP-1720 Addition of HQL (Hbase Query Language) support in Hbase Shell.
  240. The old shell syntax has been replaced by HQL, a small SQL-like
  241. set of operators, for creating, altering, dropping, inserting,
  242. deleting, and selecting, etc., data in hbase.
  243. (Inchul Song and Edward Yoon via Stack)
  244. HADOOP-1913 Build a Lucene index on an HBase table
  245. (Ning Li via Stack)
  246. HADOOP-1957 Web UI with report on cluster state and basic browsing of tables
  247. OPTIMIZATIONS
  248. BUG FIXES
  249. HADOOP-1527 Region server won't start because logdir exists
  250. HADOOP-1723 If master asks region server to shut down, by-pass return of
  251. shutdown message
  252. HADOOP-1729 Recent renaming or META tables breaks hbase shell
  253. HADOOP-1730 unexpected null value causes META scanner to exit (silently)
  254. HADOOP-1747 On a cluster, on restart, regions multiply assigned
  255. HADOOP-1776 Fix for sporadic compaction failures closing and moving
  256. compaction result
  257. HADOOP-1780 Regions are still being doubly assigned
  258. HADOOP-1797 Fix NPEs in MetaScanner constructor
  259. HADOOP-1799 Incorrect classpath in binary version of Hadoop
  260. HADOOP-1805 Region server hang on exit
  261. HADOOP-1785 TableInputFormat.TableRecordReader.next has a bug
  262. (Ning Li via Stack)
  263. HADOOP-1800 output should default utf8 encoding
  264. HADOOP-1801 When hdfs is yanked out from under hbase, hbase should go down gracefully
  265. HADOOP-1813 OOME makes zombie of region server
  266. HADOOP-1814 TestCleanRegionServerExit fails too often on Hudson
  267. HADOOP-1820 Regionserver creates hlogs without bound
  268. (reverted 2007/09/25) (Fixed 2007/09/30)
  269. HADOOP-1821 Replace all String.getBytes() with String.getBytes("UTF-8")
  270. HADOOP-1832 listTables() returns duplicate tables
  271. HADOOP-1834 Scanners ignore timestamp passed on creation
  272. HADOOP-1847 Many HBase tests do not fail well.
  273. HADOOP-1847 Many HBase tests do not fail well. (phase 2)
  274. HADOOP-1870 Once file system failure has been detected, don't check it again
  275. and get on with shutting down the hbase cluster.
  276. HADOOP-1888 NullPointerException in HMemcacheScanner (reprise)
  277. HADOOP-1903 Possible data loss if Exception happens between snapshot and
  278. flush to disk.
  279. HADOOP-1920 Wrapper scripts broken when hadoop in one location and hbase in
  280. another
  281. HADOOP-1923, HADOOP-1924 a) tests fail sporadically because set up and tear
  282. down is inconsistent b) TestDFSAbort failed in nightly #242
  283. HADOOP-1929 Add hbase-default.xml to hbase jar
  284. HADOOP-1941 StopRowFilter throws NPE when passed null row
  285. HADOOP-1966 Make HBase unit tests more reliable in the Hudson environment.
  286. HADOOP-1975 HBase tests failing with java.lang.NumberFormatException
  287. HADOOP-1990 Regression test instability affects nightly and patch builds
  288. HADOOP-1996 TestHStoreFile fails on windows if run multiple times
  289. HADOOP-1937 When the master times out a region server's lease, it is too
  290. aggressive in reclaiming the server's log.
  291. HADOOP-2004 webapp hql formatting bugs
  292. HADOOP_2011 Make hbase daemon scripts take args in same order as hadoop
  293. daemon scripts
  294. HADOOP-2017 TestRegionServerAbort failure in patch build #903 and
  295. nightly #266
  296. HADOOP-2029 TestLogRolling fails too often in patch and nightlies
  297. HADOOP-2038 TestCleanRegionExit failed in patch build #927
  298. IMPROVEMENTS
  299. HADOOP-1737 Make HColumnDescriptor data publically members settable
  300. HADOOP-1746 Clean up findbugs warnings
  301. HADOOP-1757 Bloomfilters: single argument constructor, use enum for bloom
  302. filter types
  303. HADOOP-1760 Use new MapWritable and SortedMapWritable classes from
  304. org.apache.hadoop.io
  305. HADOOP-1793 (Phase 1) Remove TestHClient (Phase2) remove HClient.
  306. HADOOP-1794 Remove deprecated APIs
  307. HADOOP-1802 Startup scripts should wait until hdfs as cleared 'safe mode'
  308. HADOOP-1833 bin/stop_hbase.sh returns before it completes
  309. (Izaak Rubin via Stack)
  310. HADOOP-1835 Updated Documentation for HBase setup/installation
  311. (Izaak Rubin via Stack)
  312. HADOOP-1868 Make default configuration more responsive
  313. HADOOP-1884 Remove useless debugging log messages from hbase.mapred
  314. HADOOP-1856 Add Jar command to hbase shell using Hadoop RunJar util
  315. (Edward Yoon via Stack)
  316. HADOOP-1928 Have master pass the regionserver the filesystem to use
  317. HADOOP-1789 Output formatting
  318. HADOOP-1960 If a region server cannot talk to the master before its lease
  319. times out, it should shut itself down
  320. HADOOP-2035 Add logo to webapps
  321. Below are the list of changes before 2007-08-18
  322. 1. HADOOP-1384. HBase omnibus patch. (jimk, Vuk Ercegovac, and Michael Stack)
  323. 2. HADOOP-1402. Fix javadoc warnings in hbase contrib. (Michael Stack)
  324. 3. HADOOP-1404. HBase command-line shutdown failing (Michael Stack)
  325. 4. HADOOP-1397. Replace custom hbase locking with
  326. java.util.concurrent.locks.ReentrantLock (Michael Stack)
  327. 5. HADOOP-1403. HBase reliability - make master and region server more fault
  328. tolerant.
  329. 6. HADOOP-1418. HBase miscellaneous: unit test for HClient, client to do
  330. 'Performance Evaluation', etc.
  331. 7. HADOOP-1420, HADOOP-1423. Findbugs changes, remove reference to removed
  332. class HLocking.
  333. 8. HADOOP-1424. TestHBaseCluster fails with IllegalMonitorStateException. Fix
  334. regression introduced by HADOOP-1397.
  335. 9. HADOOP-1426. Make hbase scripts executable + add test classes to CLASSPATH.
  336. 10. HADOOP-1430. HBase shutdown leaves regionservers up.
  337. 11. HADOOP-1392. Part1: includes create/delete table; enable/disable table;
  338. add/remove column.
  339. 12. HADOOP-1392. Part2: includes table compaction by merging adjacent regions
  340. that have shrunk in size.
  341. 13. HADOOP-1445 Support updates across region splits and compactions
  342. 14. HADOOP-1460 On shutdown IOException with complaint 'Cannot cancel lease
  343. that is not held'
  344. 15. HADOOP-1421 Failover detection, split log files.
  345. For the files modified, also clean up javadoc, class, field and method
  346. visibility (HADOOP-1466)
  347. 16. HADOOP-1479 Fix NPE in HStore#get if store file only has keys < passed key.
  348. 17. HADOOP-1476 Distributed version of 'Performance Evaluation' script
  349. 18. HADOOP-1469 Asychronous table creation
  350. 19. HADOOP-1415 Integrate BSD licensed bloom filter implementation.
  351. 20. HADOOP-1465 Add cluster stop/start scripts for hbase
  352. 21. HADOOP-1415 Provide configurable per-column bloom filters - part 2.
  353. 22. HADOOP-1498. Replace boxed types with primitives in many places.
  354. 23. HADOOP-1509. Made methods/inner classes in HRegionServer and HClient protected
  355. instead of private for easier extension. Also made HRegion and HRegionInfo public too.
  356. Added an hbase-default.xml property for specifying what HRegionInterface extension to use
  357. for proxy server connection. (James Kennedy via Jim Kellerman)
  358. 24. HADOOP-1534. [hbase] Memcache scanner fails if start key not present
  359. 25. HADOOP-1537. Catch exceptions in testCleanRegionServerExit so we can see
  360. what is failing.
  361. 26. HADOOP-1543 [hbase] Add HClient.tableExists
  362. 27. HADOOP-1519 [hbase] map/reduce interface for HBase. (Vuk Ercegovac and
  363. Jim Kellerman)
  364. 28. HADOOP-1523 Hung region server waiting on write locks
  365. 29. HADOOP-1560 NPE in MiniHBaseCluster on Windows
  366. 30. HADOOP-1531 Add RowFilter to HRegion.HScanner
  367. Adds a row filtering interface and two implemenentations: A page scanner,
  368. and a regex row/column-data matcher. (James Kennedy via Stack)
  369. 31. HADOOP-1566 Key-making utility
  370. 32. HADOOP-1415 Provide configurable per-column bloom filters.
  371. HADOOP-1466 Clean up visibility and javadoc issues in HBase.
  372. 33. HADOOP-1538 Provide capability for client specified time stamps in HBase
  373. HADOOP-1466 Clean up visibility and javadoc issues in HBase.
  374. 34. HADOOP-1589 Exception handling in HBase is broken over client server connections
  375. 35. HADOOP-1375 a simple parser for hbase (Edward Yoon via Stack)
  376. 36. HADOOP-1600 Update license in HBase code
  377. 37. HADOOP-1589 Exception handling in HBase is broken over client server
  378. 38. HADOOP-1574 Concurrent creates of a table named 'X' all succeed
  379. 39. HADOOP-1581 Un-openable tablename bug
  380. 40. HADOOP-1607 [shell] Clear screen command (Edward Yoon via Stack)
  381. 41. HADOOP-1614 [hbase] HClient does not protect itself from simultaneous updates
  382. 42. HADOOP-1468 Add HBase batch update to reduce RPC overhead
  383. 43. HADOOP-1616 Sporadic TestTable failures
  384. 44. HADOOP-1615 Replacing thread notification-based queue with
  385. java.util.concurrent.BlockingQueue in HMaster, HRegionServer
  386. 45. HADOOP-1606 Updated implementation of RowFilterSet, RowFilterInterface
  387. (Izaak Rubin via Stack)
  388. 46. HADOOP-1579 Add new WhileMatchRowFilter and StopRowFilter filters
  389. (Izaak Rubin via Stack)
  390. 47. HADOOP-1637 Fix to HScanner to Support Filters, Add Filter Tests to
  391. TestScanner2 (Izaak Rubin via Stack)
  392. 48. HADOOP-1516 HClient fails to readjust when ROOT or META redeployed on new
  393. region server
  394. 49. HADOOP-1646 RegionServer OOME's under sustained, substantial loading by
  395. 10 concurrent clients
  396. 50. HADOOP-1468 Add HBase batch update to reduce RPC overhead (restrict batches
  397. to a single row at a time)
  398. 51. HADOOP-1528 HClient for multiple tables (phase 1) (James Kennedy & JimK)
  399. 52. HADOOP-1528 HClient for multiple tables (phase 2) all HBase client side code
  400. (except TestHClient and HBaseShell) have been converted to use the new client
  401. side objects (HTable/HBaseAdmin/HConnection) instead of HClient.
  402. 53. HADOOP-1528 HClient for multiple tables - expose close table function
  403. 54. HADOOP-1466 Clean up warnings, visibility and javadoc issues in HBase.
  404. 55. HADOOP-1662 Make region splits faster
  405. 56. HADOOP-1678 On region split, master should designate which host should
  406. serve daughter splits. Phase 1: Master balances load for new regions and
  407. when a region server fails.
  408. 57. HADOOP-1678 On region split, master should designate which host should
  409. serve daughter splits. Phase 2: Master assigns children of split region
  410. instead of HRegionServer serving both children.
  411. 58. HADOOP-1710 All updates should be batch updates
  412. 59. HADOOP-1711 HTable API should use interfaces instead of concrete classes as
  413. method parameters and return values
  414. 60. HADOOP-1644 Compactions should not block updates
  415. 60. HADOOP-1672 HBase Shell should use new client classes
  416. (Edward Yoon via Stack).
  417. 61. HADOOP-1709 Make HRegionInterface more like that of HTable
  418. HADOOP-1725 Client find of table regions should not include offlined, split parents