Return-Path: X-Original-To: archive-asf-public-internal@cust-asf2.ponee.io Delivered-To: archive-asf-public-internal@cust-asf2.ponee.io Received: from cust-asf.ponee.io (cust-asf.ponee.io [163.172.22.183]) by cust-asf2.ponee.io (Postfix) with ESMTP id F11D0200BC3 for ; Fri, 18 Nov 2016 19:56:03 +0100 (CET) Received: by cust-asf.ponee.io (Postfix) id EFA78160B21; Fri, 18 Nov 2016 18:56:03 +0000 (UTC) Delivered-To: archive-asf-public@cust-asf.ponee.io Received: from mail.apache.org (hermes.apache.org [140.211.11.3]) by cust-asf.ponee.io (Postfix) with SMTP id EFA2A160B1E for ; Fri, 18 Nov 2016 19:56:01 +0100 (CET) Received: (qmail 38366 invoked by uid 500); 18 Nov 2016 18:55:58 -0000 Mailing-List: contact commits-help@hbase.apache.org; run by ezmlm Precedence: bulk List-Help: List-Unsubscribe: List-Post: List-Id: Reply-To: dev@hbase.apache.org Delivered-To: mailing list commits@hbase.apache.org Received: (qmail 36441 invoked by uid 99); 18 Nov 2016 18:55:57 -0000 Received: from git1-us-west.apache.org (HELO git1-us-west.apache.org) (140.211.11.23) by apache.org (qpsmtpd/0.29) with ESMTP; Fri, 18 Nov 2016 18:55:57 +0000 Received: by git1-us-west.apache.org (ASF Mail Server at git1-us-west.apache.org, from userid 33) id 10EDAE00B3; Fri, 18 Nov 2016 18:55:57 +0000 (UTC) Content-Type: text/plain; charset="us-ascii" MIME-Version: 1.0 Content-Transfer-Encoding: 7bit From: stack@apache.org To: commits@hbase.apache.org Date: Fri, 18 Nov 2016 18:56:18 -0000 Message-Id: <87d8df63bff4492fad286c6572fce9f7@git.apache.org> In-Reply-To: <71d1e1d206dc41a7b8b041b4ba6d5329@git.apache.org> References: <71d1e1d206dc41a7b8b041b4ba6d5329@git.apache.org> X-Mailer: ASF-Git Admin Mailer Subject: [23/51] [partial] hbase-site git commit: HBASE-17121 Undo the building of xref as part of site build; remove xref dirs archived-at: Fri, 18 Nov 2016 18:56:04 -0000 http://git-wip-us.apache.org/repos/asf/hbase-site/blob/7b604147/xref-test/org/apache/hadoop/hbase/TestCompatibilitySingletonFactory.html ---------------------------------------------------------------------- diff --git a/xref-test/org/apache/hadoop/hbase/TestCompatibilitySingletonFactory.html b/xref-test/org/apache/hadoop/hbase/TestCompatibilitySingletonFactory.html deleted file mode 100644 index b393dbd..0000000 --- a/xref-test/org/apache/hadoop/hbase/TestCompatibilitySingletonFactory.html +++ /dev/null @@ -1,103 +0,0 @@ - - - - -TestCompatibilitySingletonFactory xref - - - -
-
-1   /**
-2    * Licensed to the Apache Software Foundation (ASF) under one
-3    * or more contributor license agreements.  See the NOTICE file
-4    * distributed with this work for additional information
-5    * regarding copyright ownership.  The ASF licenses this file
-6    * to you under the Apache License, Version 2.0 (the
-7    * "License"); you may not use this file except in compliance
-8    * with the License.  You may obtain a copy of the License at
-9    *
-10   *     http://www.apache.org/licenses/LICENSE-2.0
-11   *
-12   * Unless required by applicable law or agreed to in writing, software
-13   * distributed under the License is distributed on an "AS IS" BASIS,
-14   * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-15   * See the License for the specific language governing permissions and
-16   * limitations under the License.
-17   */
-18  
-19  package org.apache.hadoop.hbase;
-20  
-21  import java.util.ArrayList;
-22  import java.util.List;
-23  import java.util.Random;
-24  import java.util.concurrent.Callable;
-25  import java.util.concurrent.ExecutorService;
-26  import java.util.concurrent.Executors;
-27  import java.util.concurrent.Future;
-28  
-29  import org.apache.hadoop.hbase.testclassification.SmallTests;
-30  import org.apache.hadoop.hbase.testclassification.MetricsTests;
-31  
-32  import org.junit.Test;
-33  import org.junit.experimental.categories.Category;
-34  
-35  import static org.junit.Assert.assertEquals;
-36  import static org.junit.Assert.assertNotEquals;
-37  
-38  @Category({MetricsTests.class, SmallTests.class})
-39  public class TestCompatibilitySingletonFactory {
-40  
-41    private static final int ITERATIONS = 100000;
-42    private static final Random RANDOM = new Random();
-43  
-44    private class TestCompatibilitySingletonFactoryCallable implements Callable<String> {
-45  
-46      @Override
-47      public String call() throws Exception {
-48        Thread.sleep(RANDOM.nextInt(10));
-49        RandomStringGenerator
-50            instance =
-51            CompatibilitySingletonFactory.getInstance(RandomStringGenerator.class);
-52        return instance.getRandString();
-53      }
-54    }
-55  
-56    @Test
-57    public void testGetInstance() throws Exception {
-58      List<TestCompatibilitySingletonFactoryCallable> callables =
-59          new ArrayList<TestCompatibilitySingletonFactoryCallable>(ITERATIONS);
-60      List<String> resultStrings = new ArrayList<String>(ITERATIONS);
-61  
-62  
-63      // Create the callables.
-64      for (int i = 0; i < ITERATIONS; i++) {
-65        callables.add(new TestCompatibilitySingletonFactoryCallable());
-66      }
-67  
-68      // Now run the callables.
-69      ExecutorService executorService = Executors.newFixedThreadPool(100);
-70      List<Future<String>> futures = executorService.invokeAll(callables);
-71  
-72      // Wait for them all to finish.
-73      for (Future<String> f : futures) {
-74        resultStrings.add(f.get());
-75      }
-76  
-77      // Get the first string.
-78      String firstString = resultStrings.get(0);
-79  
-80  
-81      // Assert that all the strings are equal to the fist.
-82      for (String s : resultStrings) {
-83        assertEquals(firstString, s);
-84      }
-85  
-86      // an assert to make sure that RandomStringGeneratorImpl is generating random strings.
-87      assertNotEquals(new RandomStringGeneratorImpl().getRandString(), firstString);
-88    }
-89  }
-
-
- - http://git-wip-us.apache.org/repos/asf/hbase-site/blob/7b604147/xref-test/org/apache/hadoop/hbase/TestCompoundConfiguration.html ---------------------------------------------------------------------- diff --git a/xref-test/org/apache/hadoop/hbase/TestCompoundConfiguration.html b/xref-test/org/apache/hadoop/hbase/TestCompoundConfiguration.html deleted file mode 100644 index f5859f7..0000000 --- a/xref-test/org/apache/hadoop/hbase/TestCompoundConfiguration.html +++ /dev/null @@ -1,242 +0,0 @@ - - - - -TestCompoundConfiguration xref - - - -
-
-1   /**
-2    * Copyright The Apache Software Foundation
-3    *
-4    * Licensed to the Apache Software Foundation (ASF) under one
-5    * or more contributor license agreements.  See the NOTICE file
-6    * distributed with this work for additional information
-7    * regarding copyright ownership.  The ASF licenses this file
-8    * to you under the Apache License, Version 2.0 (the
-9    * "License"); you may not use this file except in compliance
-10   * with the License.  You may obtain a copy of the License at
-11   *
-12   *     http://www.apache.org/licenses/LICENSE-2.0
-13   *
-14   * Unless required by applicable law or agreed to in writing, software
-15   * distributed under the License is distributed on an "AS IS" BASIS,
-16   * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-17   * See the License for the specific language governing permissions and
-18   * limitations under the License.
-19   */
-20  package org.apache.hadoop.hbase;
-21  
-22  import java.util.HashMap;
-23  import java.util.Map;
-24  
-25  import junit.framework.TestCase;
-26  
-27  import org.apache.hadoop.conf.Configuration;
-28  import org.apache.hadoop.hbase.testclassification.MiscTests;
-29  import org.apache.hadoop.hbase.testclassification.SmallTests;
-30  import org.apache.hadoop.hbase.util.Bytes;
-31  import org.junit.Test;
-32  import org.junit.experimental.categories.Category;
-33  
-34  @Category({MiscTests.class, SmallTests.class})
-35  public class TestCompoundConfiguration extends TestCase {
-36    private Configuration baseConf;
-37    private int baseConfSize;
-38  
-39    @Override
-40    protected void setUp() throws Exception {
-41      baseConf = new Configuration();
-42      baseConf.set("A", "1");
-43      baseConf.setInt("B", 2);
-44      baseConf.set("C", "3");
-45      baseConfSize = baseConf.size();
-46    }
-47  
-48    @Test
-49    public void testBasicFunctionality() throws ClassNotFoundException {
-50      CompoundConfiguration compoundConf = new CompoundConfiguration()
-51          .add(baseConf); 
-52      assertEquals("1", compoundConf.get("A"));
-53      assertEquals(2, compoundConf.getInt("B", 0));
-54      assertEquals(3, compoundConf.getInt("C", 0));
-55      assertEquals(0, compoundConf.getInt("D", 0));
-56  
-57      assertEquals(CompoundConfiguration.class, compoundConf
-58          .getClassByName(CompoundConfiguration.class.getName()));
-59      try {
-60        compoundConf.getClassByName("bad_class_name");
-61        fail("Trying to load bad_class_name should throw an exception");
-62      } catch (ClassNotFoundException e) {
-63        // win!
-64      }
-65    }
-66  
-67    @Test
-68    public void testPut() {
-69      CompoundConfiguration compoundConf = new CompoundConfiguration()
-70        .add(baseConf);
-71      assertEquals("1", compoundConf.get("A"));
-72      assertEquals(2, compoundConf.getInt("B", 0));
-73      assertEquals(3, compoundConf.getInt("C", 0));
-74      assertEquals(0, compoundConf.getInt("D", 0));
-75  
-76      compoundConf.set("A", "1337");
-77      compoundConf.set("string", "stringvalue");
-78      assertEquals(1337, compoundConf.getInt("A", 0));
-79      assertEquals("stringvalue", compoundConf.get("string"));
-80  
-81      // we didn't modify the base conf
-82      assertEquals("1", baseConf.get("A"));
-83      assertNull(baseConf.get("string"));
-84  
-85      // adding to the base shows up in the compound
-86      baseConf.set("setInParent", "fromParent");
-87      assertEquals("fromParent", compoundConf.get("setInParent"));
-88    }
-89  
-90    @Test
-91    public void testWithConfig() {
-92      Configuration conf = new Configuration();
-93      conf.set("B", "2b");
-94      conf.set("C", "33");
-95      conf.set("D", "4");
-96  
-97      CompoundConfiguration compoundConf = new CompoundConfiguration()
-98          .add(baseConf)
-99          .add(conf);
-100     assertEquals("1", compoundConf.get("A"));
-101     assertEquals("2b", compoundConf.get("B"));
-102     assertEquals(33, compoundConf.getInt("C", 0));
-103     assertEquals("4", compoundConf.get("D"));
-104     assertEquals(4, compoundConf.getInt("D", 0));
-105     assertNull(compoundConf.get("E"));
-106     assertEquals(6, compoundConf.getInt("F", 6));
-107     
-108     int cnt = 0;
-109     for (Map.Entry<String,String> entry : compoundConf) {
-110       cnt++;
-111       if (entry.getKey().equals("B")) assertEquals("2b", entry.getValue());
-112       else if (entry.getKey().equals("G")) assertEquals(null, entry.getValue());
-113     }
-114     // verify that entries from ImmutableConfigMap's are merged in the iterator's view
-115     assertEquals(baseConfSize + 1, cnt);
-116   }
-117 
-118   private Bytes strToIb(String s) {
-119     return new Bytes(Bytes.toBytes(s));
-120   }
-121 
-122   @Test
-123   public void testWithIbwMap() {
-124     Map<Bytes, Bytes> map =
-125       new HashMap<Bytes, Bytes>();
-126     map.put(strToIb("B"), strToIb("2b"));
-127     map.put(strToIb("C"), strToIb("33"));
-128     map.put(strToIb("D"), strToIb("4"));
-129     // unlike config, note that IBW Maps can accept null values
-130     map.put(strToIb("G"), null);
-131 
-132     CompoundConfiguration compoundConf = new CompoundConfiguration()
-133       .add(baseConf)
-134       .addBytesMap(map);
-135     assertEquals("1", compoundConf.get("A"));
-136     assertEquals("2b", compoundConf.get("B"));
-137     assertEquals(33, compoundConf.getInt("C", 0));
-138     assertEquals("4", compoundConf.get("D"));
-139     assertEquals(4, compoundConf.getInt("D", 0));
-140     assertNull(compoundConf.get("E"));
-141     assertEquals(6, compoundConf.getInt("F", 6));
-142     assertNull(compoundConf.get("G"));
-143     
-144     int cnt = 0;
-145     for (Map.Entry<String,String> entry : compoundConf) {
-146       cnt++;
-147       if (entry.getKey().equals("B")) assertEquals("2b", entry.getValue());
-148       else if (entry.getKey().equals("G")) assertEquals(null, entry.getValue());
-149     }
-150     // verify that entries from ImmutableConfigMap's are merged in the iterator's view
-151     assertEquals(baseConfSize + 2, cnt);
-152 
-153     // Verify that adding map after compound configuration is modified overrides properly
-154     CompoundConfiguration conf2 = new CompoundConfiguration();
-155     conf2.set("X", "modification");
-156     conf2.set("D", "not4");
-157     assertEquals("modification", conf2.get("X"));
-158     assertEquals("not4", conf2.get("D"));
-159     conf2.addBytesMap(map);
-160     assertEquals("4", conf2.get("D")); // map overrides
-161   }
-162 
-163   @Test
-164   public void testWithStringMap() {
-165     Map<String, String> map = new HashMap<String, String>();
-166     map.put("B", "2b");
-167     map.put("C", "33");
-168     map.put("D", "4");
-169     // unlike config, note that IBW Maps can accept null values
-170     map.put("G", null);
-171 
-172     CompoundConfiguration compoundConf = new CompoundConfiguration().addStringMap(map);
-173     assertEquals("2b", compoundConf.get("B"));
-174     assertEquals(33, compoundConf.getInt("C", 0));
-175     assertEquals("4", compoundConf.get("D"));
-176     assertEquals(4, compoundConf.getInt("D", 0));
-177     assertNull(compoundConf.get("E"));
-178     assertEquals(6, compoundConf.getInt("F", 6));
-179     assertNull(compoundConf.get("G"));
-180 
-181     int cnt = 0;
-182     for (Map.Entry<String,String> entry : compoundConf) {
-183       cnt++;
-184       if (entry.getKey().equals("B")) assertEquals("2b", entry.getValue());
-185       else if (entry.getKey().equals("G")) assertEquals(null, entry.getValue());
-186     }
-187     // verify that entries from ImmutableConfigMap's are merged in the iterator's view
-188     assertEquals(4, cnt);
-189     
-190     // Verify that adding map after compound configuration is modified overrides properly
-191     CompoundConfiguration conf2 = new CompoundConfiguration();
-192     conf2.set("X", "modification");
-193     conf2.set("D", "not4");
-194     assertEquals("modification", conf2.get("X"));
-195     assertEquals("not4", conf2.get("D"));
-196     conf2.addStringMap(map);
-197     assertEquals("4", conf2.get("D")); // map overrides
-198   }
-199 
-200   @Test
-201   public void testLaterConfigsOverrideEarlier() {
-202     Map<String, String> map1 = new HashMap<String, String>();
-203     map1.put("A", "2");
-204     map1.put("D", "5");
-205     Map<String, String> map2 = new HashMap<String, String>();
-206     String newValueForA = "3", newValueForB = "4";
-207     map2.put("A", newValueForA);
-208     map2.put("B", newValueForB);
-209 
-210     CompoundConfiguration compoundConf = new CompoundConfiguration()
-211       .addStringMap(map1).add(baseConf);
-212     assertEquals("1", compoundConf.get("A"));
-213     assertEquals("5", compoundConf.get("D"));
-214     compoundConf.addStringMap(map2);
-215     assertEquals(newValueForA, compoundConf.get("A"));
-216     assertEquals(newValueForB, compoundConf.get("B"));
-217     assertEquals("5", compoundConf.get("D"));
-218 
-219     int cnt = 0;
-220     for (Map.Entry<String,String> entry : compoundConf) {
-221       cnt++;
-222       if (entry.getKey().equals("A")) assertEquals(newValueForA, entry.getValue());
-223       else if (entry.getKey().equals("B")) assertEquals(newValueForB, entry.getValue());
-224     }
-225     // verify that entries from ImmutableConfigMap's are merged in the iterator's view
-226     assertEquals(baseConfSize + 1, cnt);
-227   }
-228 }
-
-
- - http://git-wip-us.apache.org/repos/asf/hbase-site/blob/7b604147/xref-test/org/apache/hadoop/hbase/TestFSTableDescriptorForceCreation.html ---------------------------------------------------------------------- diff --git a/xref-test/org/apache/hadoop/hbase/TestFSTableDescriptorForceCreation.html b/xref-test/org/apache/hadoop/hbase/TestFSTableDescriptorForceCreation.html deleted file mode 100644 index 8a31ae7..0000000 --- a/xref-test/org/apache/hadoop/hbase/TestFSTableDescriptorForceCreation.html +++ /dev/null @@ -1,91 +0,0 @@ - - - - -TestFSTableDescriptorForceCreation xref - - - -
-
-1   /**
-2    *
-3    * Licensed to the Apache Software Foundation (ASF) under one
-4    * or more contributor license agreements.  See the NOTICE file
-5    * distributed with this work for additional information
-6    * regarding copyright ownership.  The ASF licenses this file
-7    * to you under the Apache License, Version 2.0 (the
-8    * "License"); you may not use this file except in compliance
-9    * with the License.  You may obtain a copy of the License at
-10   *
-11   *     http://www.apache.org/licenses/LICENSE-2.0
-12   *
-13   * Unless required by applicable law or agreed to in writing, software
-14   * distributed under the License is distributed on an "AS IS" BASIS,
-15   * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-16   * See the License for the specific language governing permissions and
-17   * limitations under the License.
-18   */
-19  package org.apache.hadoop.hbase;
-20  
-21  import static org.junit.Assert.assertFalse;
-22  import static org.junit.Assert.assertTrue;
-23  
-24  import java.io.IOException;
-25  
-26  import org.apache.hadoop.fs.FileSystem;
-27  import org.apache.hadoop.fs.Path;
-28  import org.apache.hadoop.hbase.testclassification.MiscTests;
-29  import org.apache.hadoop.hbase.testclassification.SmallTests;
-30  import org.apache.hadoop.hbase.util.FSTableDescriptors;
-31  import org.junit.*;
-32  import org.junit.experimental.categories.Category;
-33  
-34  @Category({MiscTests.class, SmallTests.class})
-35  public class TestFSTableDescriptorForceCreation {
-36    private static final HBaseTestingUtility UTIL = new HBaseTestingUtility();
-37  
-38    @Test
-39    public void testShouldCreateNewTableDescriptorIfForcefulCreationIsFalse()
-40        throws IOException {
-41      final String name = "newTable2";
-42      FileSystem fs = FileSystem.get(UTIL.getConfiguration());
-43      Path rootdir = new Path(UTIL.getDataTestDir(), name);
-44      FSTableDescriptors fstd = new FSTableDescriptors(UTIL.getConfiguration(), fs, rootdir);
-45      HTableDescriptor htd = new HTableDescriptor(TableName.valueOf(name));
-46  
-47      assertTrue("Should create new table descriptor", fstd.createTableDescriptor(htd, false));
-48    }
-49  
-50    @Test
-51    public void testShouldNotCreateTheSameTableDescriptorIfForcefulCreationIsFalse()
-52        throws IOException {
-53      final String name = "testAlreadyExists";
-54      FileSystem fs = FileSystem.get(UTIL.getConfiguration());
-55      // Cleanup old tests if any detritus laying around.
-56      Path rootdir = new Path(UTIL.getDataTestDir(), name);
-57      FSTableDescriptors fstd = new FSTableDescriptors(UTIL.getConfiguration(), fs, rootdir);
-58      HTableDescriptor htd = new HTableDescriptor(name);
-59      fstd.add(htd);
-60      assertFalse("Should not create new table descriptor", fstd.createTableDescriptor(htd, false));
-61    }
-62  
-63    @Test
-64    public void testShouldAllowForcefulCreationOfAlreadyExistingTableDescriptor()
-65        throws Exception {
-66      final String name = "createNewTableNew2";
-67      FileSystem fs = FileSystem.get(UTIL.getConfiguration());
-68      Path rootdir = new Path(UTIL.getDataTestDir(), name);
-69      FSTableDescriptors fstd = new FSTableDescriptors(UTIL.getConfiguration(), fs, rootdir);
-70      HTableDescriptor htd = new HTableDescriptor(TableName.valueOf(name));
-71      fstd.createTableDescriptor(htd, false);
-72      assertTrue("Should create new table descriptor",
-73          fstd.createTableDescriptor(htd, true));
-74    }
-75  
-76  }
-77  
-
-
- - http://git-wip-us.apache.org/repos/asf/hbase-site/blob/7b604147/xref-test/org/apache/hadoop/hbase/TestFullLogReconstruction.html ---------------------------------------------------------------------- diff --git a/xref-test/org/apache/hadoop/hbase/TestFullLogReconstruction.html b/xref-test/org/apache/hadoop/hbase/TestFullLogReconstruction.html deleted file mode 100644 index 9541960..0000000 --- a/xref-test/org/apache/hadoop/hbase/TestFullLogReconstruction.html +++ /dev/null @@ -1,108 +0,0 @@ - - - - -TestFullLogReconstruction xref - - - -
-
-1   /**
-2    *
-3    * Licensed to the Apache Software Foundation (ASF) under one
-4    * or more contributor license agreements.  See the NOTICE file
-5    * distributed with this work for additional information
-6    * regarding copyright ownership.  The ASF licenses this file
-7    * to you under the Apache License, Version 2.0 (the
-8    * "License"); you may not use this file except in compliance
-9    * with the License.  You may obtain a copy of the License at
-10   *
-11   *     http://www.apache.org/licenses/LICENSE-2.0
-12   *
-13   * Unless required by applicable law or agreed to in writing, software
-14   * distributed under the License is distributed on an "AS IS" BASIS,
-15   * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-16   * See the License for the specific language governing permissions and
-17   * limitations under the License.
-18   */
-19  
-20  package org.apache.hadoop.hbase;
-21  
-22  import static org.junit.Assert.assertEquals;
-23  
-24  import org.apache.hadoop.conf.Configuration;
-25  import org.apache.hadoop.hbase.client.Table;
-26  import org.apache.hadoop.hbase.testclassification.LargeTests;
-27  import org.apache.hadoop.hbase.testclassification.MiscTests;
-28  import org.apache.hadoop.hbase.util.Bytes;
-29  import org.junit.AfterClass;
-30  import org.junit.BeforeClass;
-31  import org.junit.Test;
-32  import org.junit.experimental.categories.Category;
-33
-34  @Category({ MiscTests.class, LargeTests.class })
-35  public class TestFullLogReconstruction {
-36
-37    private final static HBaseTestingUtility
-38        TEST_UTIL = new HBaseTestingUtility();
-39
-40    private final static TableName TABLE_NAME = TableName.valueOf("tabletest");
-41    private final static byte[] FAMILY = Bytes.toBytes("family");
-42
-43    /**
-44     * @throws java.lang.Exception
-45     */
-46    @BeforeClass
-47    public static void setUpBeforeClass() throws Exception {
-48      Configuration c = TEST_UTIL.getConfiguration();
-49      // quicker heartbeat interval for faster DN death notification
-50      c.setInt("dfs.namenode.heartbeat.recheck-interval", 5000);
-51      c.setInt("dfs.heartbeat.interval", 1);
-52      c.setInt("dfs.client.socket-timeout", 5000);
-53      // faster failover with cluster.shutdown();fs.close() idiom
-54      c.setInt("hbase.ipc.client.connect.max.retries", 1);
-55      c.setInt("dfs.client.block.recovery.retries", 1);
-56      c.setInt(HConstants.ZK_SESSION_TIMEOUT, 1000);
-57      TEST_UTIL.startMiniCluster(3);
-58    }
-59
-60    /**
-61     * @throws java.lang.Exception
-62     */
-63    @AfterClass
-64    public static void tearDownAfterClass() throws Exception {
-65      TEST_UTIL.shutdownMiniCluster();
-66    }
-67
-68    /**
-69     * Test the whole reconstruction loop. Build a table with regions aaa to zzz
-70     * and load every one of them multiple times with the same date and do a flush
-71     * at some point. Kill one of the region servers and scan the table. We should
-72     * see all the rows.
-73     * @throws Exception
-74     */
-75    @Test (timeout=300000)
-76    public void testReconstruction() throws Exception {
-77      Table table = TEST_UTIL.createMultiRegionTable(TABLE_NAME, FAMILY);
-78
-79      // Load up the table with simple rows and count them
-80      int initialCount = TEST_UTIL.loadTable(table, FAMILY);
-81      int count = TEST_UTIL.countRows(table);
-82
-83      assertEquals(initialCount, count);
-84
-85      for(int i = 0; i < 4; i++) {
-86        TEST_UTIL.loadTable(table, FAMILY);
-87      }
-88
-89      TEST_UTIL.expireRegionServerSession(0);
-90      int newCount = TEST_UTIL.countRows(table);
-91      assertEquals(count, newCount);
-92      table.close();
-93    }
-94  }
-
-
- -