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 8CA6B200CC7 for ; Sun, 2 Jul 2017 01:44:02 +0200 (CEST) Received: by cust-asf.ponee.io (Postfix) id 8BC02160C01; Sat, 1 Jul 2017 23:44:02 +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 3367B160BEA for ; Sun, 2 Jul 2017 01:44:00 +0200 (CEST) Received: (qmail 26936 invoked by uid 500); 1 Jul 2017 23:43:57 -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 26430 invoked by uid 99); 1 Jul 2017 23:43: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; Sat, 01 Jul 2017 23:43:57 +0000 Received: by git1-us-west.apache.org (ASF Mail Server at git1-us-west.apache.org, from userid 33) id 3F975F54E0; Sat, 1 Jul 2017 23:43:55 +0000 (UTC) Content-Type: text/plain; charset="us-ascii" MIME-Version: 1.0 Content-Transfer-Encoding: 7bit From: git-site-role@apache.org To: commits@hbase.apache.org Date: Sat, 01 Jul 2017 23:44:03 -0000 Message-Id: In-Reply-To: <7acdac7676004726a47bdcef7bac7d48@git.apache.org> References: <7acdac7676004726a47bdcef7bac7d48@git.apache.org> X-Mailer: ASF-Git Admin Mailer Subject: [10/21] hbase-site git commit: Published site at 82d554e3783372cc6b05489452c815b57c06f6cd. archived-at: Sat, 01 Jul 2017 23:44:02 -0000 http://git-wip-us.apache.org/repos/asf/hbase-site/blob/640333c3/testdevapidocs/org/apache/hadoop/hbase/mapreduce/TableSnapshotInputFormatTestBase.html ---------------------------------------------------------------------- diff --git a/testdevapidocs/org/apache/hadoop/hbase/mapreduce/TableSnapshotInputFormatTestBase.html b/testdevapidocs/org/apache/hadoop/hbase/mapreduce/TableSnapshotInputFormatTestBase.html index a390186..f61aa48 100644 --- a/testdevapidocs/org/apache/hadoop/hbase/mapreduce/TableSnapshotInputFormatTestBase.html +++ b/testdevapidocs/org/apache/hadoop/hbase/mapreduce/TableSnapshotInputFormatTestBase.html @@ -113,7 +113,7 @@ var activeTableTab = "activeTableTab";

-
public abstract class TableSnapshotInputFormatTestBase
+
public abstract class TableSnapshotInputFormatTestBase
 extends Object
@@ -142,18 +142,22 @@ extends fs  +private static org.apache.commons.logging.Log +LOG  + + protected static int NUM_REGION_SERVERS  - + protected org.apache.hadoop.fs.Path rootDir  - + org.junit.rules.TestRule timeout  - + protected HBaseTestingUtility UTIL  @@ -300,13 +304,22 @@ extends + + +
    +
  • +

    LOG

    +
    private static final org.apache.commons.logging.Log LOG
    +
  • +
  • timeout

    -
    public final org.junit.rules.TestRule timeout
    +
    public final org.junit.rules.TestRule timeout
@@ -315,7 +328,7 @@ extends
  • UTIL

    -
    protected final HBaseTestingUtility UTIL
    +
    protected final HBaseTestingUtility UTIL
  • @@ -324,7 +337,7 @@ extends
  • NUM_REGION_SERVERS

    -
    protected static final int NUM_REGION_SERVERS
    +
    protected static final int NUM_REGION_SERVERS
    See Also:
    Constant Field Values
    @@ -337,7 +350,7 @@ extends
  • FAMILIES

    -
    protected static final byte[][] FAMILIES
    +
    protected static final byte[][] FAMILIES
  • @@ -346,7 +359,7 @@ extends
  • fs

    -
    protected org.apache.hadoop.fs.FileSystem fs
    +
    protected org.apache.hadoop.fs.FileSystem fs
  • @@ -355,7 +368,7 @@ extends
  • rootDir

    -
    protected org.apache.hadoop.fs.Path rootDir
    +
    protected org.apache.hadoop.fs.Path rootDir
  • @@ -372,7 +385,7 @@ extends
  • TableSnapshotInputFormatTestBase

    -
    public TableSnapshotInputFormatTestBase()
    +
    public TableSnapshotInputFormatTestBase()
  • @@ -389,7 +402,7 @@ extends
  • setupCluster

    -
    public void setupCluster()
    +
    public void setupCluster()
                       throws Exception
    Throws:
    @@ -403,7 +416,7 @@ extends
  • tearDownCluster

    -
    public void tearDownCluster()
    +
    public void tearDownCluster()
                          throws Exception
    Throws:
    @@ -417,7 +430,7 @@ extends
  • setupConf

    -
    private static void setupConf(org.apache.hadoop.conf.Configuration conf)
    +
    private static void setupConf(org.apache.hadoop.conf.Configuration conf)
  • @@ -426,7 +439,7 @@ extends
  • testWithMockedMapReduce

    -
    protected abstract void testWithMockedMapReduce(HBaseTestingUtility util,
    +
    protected abstract void testWithMockedMapReduce(HBaseTestingUtility util,
                                                     String snapshotName,
                                                     int numRegions,
                                                     int expectedNumSplits)
    @@ -443,7 +456,7 @@ extends 
     
  • testWithMapReduceImpl

    -
    protected abstract void testWithMapReduceImpl(HBaseTestingUtility util,
    +
    protected abstract void testWithMapReduceImpl(HBaseTestingUtility util,
                                                   org.apache.hadoop.hbase.TableName tableName,
                                                   String snapshotName,
                                                   org.apache.hadoop.fs.Path tableDir,
    @@ -463,7 +476,7 @@ extends 
     
  • getStartRow

    -
    protected abstract byte[] getStartRow()
    +
    protected abstract byte[] getStartRow()
  • @@ -472,7 +485,7 @@ extends
  • getEndRow

    -
    protected abstract byte[] getEndRow()
    +
    protected abstract byte[] getEndRow()
  • @@ -481,7 +494,7 @@ extends
  • testWithMockedMapReduceSingleRegion

    -
    public void testWithMockedMapReduceSingleRegion()
    +
    public void testWithMockedMapReduceSingleRegion()
                                              throws Exception
    Throws:
    @@ -495,7 +508,7 @@ extends
  • testWithMockedMapReduceMultiRegion

    -
    public void testWithMockedMapReduceMultiRegion()
    +
    public void testWithMockedMapReduceMultiRegion()
                                             throws Exception
    Throws:
    @@ -509,7 +522,7 @@ extends
  • testWithMapReduceSingleRegion

    -
    public void testWithMapReduceSingleRegion()
    +
    public void testWithMapReduceSingleRegion()
                                        throws Exception
    Throws:
    @@ -523,7 +536,7 @@ extends
  • testWithMapReduceMultiRegion

    -
    public void testWithMapReduceMultiRegion()
    +
    public void testWithMapReduceMultiRegion()
                                       throws Exception
    Throws:
    @@ -537,7 +550,7 @@ extends
  • testWithMapReduceAndOfflineHBaseMultiRegion

    -
    public void testWithMapReduceAndOfflineHBaseMultiRegion()
    +
    public void testWithMapReduceAndOfflineHBaseMultiRegion()
                                                      throws Exception
    Throws:
    @@ -551,7 +564,7 @@ extends
  • testRestoreSnapshotDoesNotCreateBackRefLinks

    -
    public void testRestoreSnapshotDoesNotCreateBackRefLinks()
    +
    public void testRestoreSnapshotDoesNotCreateBackRefLinks()
                                                       throws Exception
    Throws:
    @@ -565,7 +578,7 @@ extends
  • testRestoreSnapshotDoesNotCreateBackRefLinksInit

    -
    public abstract void testRestoreSnapshotDoesNotCreateBackRefLinksInit(org.apache.hadoop.hbase.TableName tableName,
    +
    public abstract void testRestoreSnapshotDoesNotCreateBackRefLinksInit(org.apache.hadoop.hbase.TableName tableName,
                                                                           String snapshotName,
                                                                           org.apache.hadoop.fs.Path tmpTableDir)
                                                                    throws Exception
    @@ -581,7 +594,7 @@ extends
  • testWithMapReduce

    -
    protected void testWithMapReduce(HBaseTestingUtility util,
    +
    protected void testWithMapReduce(HBaseTestingUtility util,
                                      String snapshotName,
                                      int numRegions,
                                      int expectedNumSplits,
    @@ -599,7 +612,7 @@ extends 
     
  • verifyRowFromMap

    -
    protected static void verifyRowFromMap(org.apache.hadoop.hbase.io.ImmutableBytesWritable key,
    +
    protected static void verifyRowFromMap(org.apache.hadoop.hbase.io.ImmutableBytesWritable key,
                                            org.apache.hadoop.hbase.client.Result result)
                                     throws IOException
    @@ -614,7 +627,7 @@ extends
  • createTableAndSnapshot

    -
    protected static void createTableAndSnapshot(HBaseTestingUtility util,
    +
    protected static void createTableAndSnapshot(HBaseTestingUtility util,
                                                  org.apache.hadoop.hbase.TableName tableName,
                                                  String snapshotName,
                                                  byte[] startRow,
    
    http://git-wip-us.apache.org/repos/asf/hbase-site/blob/640333c3/testdevapidocs/org/apache/hadoop/hbase/mapreduce/TestTableSnapshotInputFormat.TestTableSnapshotCounters.html
    ----------------------------------------------------------------------
    diff --git a/testdevapidocs/org/apache/hadoop/hbase/mapreduce/TestTableSnapshotInputFormat.TestTableSnapshotCounters.html b/testdevapidocs/org/apache/hadoop/hbase/mapreduce/TestTableSnapshotInputFormat.TestTableSnapshotCounters.html
    index a802314..aca2b9c 100644
    --- a/testdevapidocs/org/apache/hadoop/hbase/mapreduce/TestTableSnapshotInputFormat.TestTableSnapshotCounters.html
    +++ b/testdevapidocs/org/apache/hadoop/hbase/mapreduce/TestTableSnapshotInputFormat.TestTableSnapshotCounters.html
    @@ -122,7 +122,7 @@ var activeTableTab = "activeTableTab";
     


  • -
    public static enum TestTableSnapshotInputFormat.TestTableSnapshotCounters
    +
    public static enum TestTableSnapshotInputFormat.TestTableSnapshotCounters
     extends Enum<TestTableSnapshotInputFormat.TestTableSnapshotCounters>
  • @@ -207,7 +207,7 @@ the order they are declared.
  • @@ -224,7 +224,7 @@ the order they are declared.
    • values

      -
      public static TestTableSnapshotInputFormat.TestTableSnapshotCounters[] values()
      +
      public static TestTableSnapshotInputFormat.TestTableSnapshotCounters[] values()
      Returns an array containing the constants of this enum type, in the order they are declared. This method may be used to iterate over the constants as follows: @@ -244,7 +244,7 @@ for (TestTableSnapshotInputFormat.TestTableSnapshotCounters c : TestTableSnapsho
      • valueOf

        -
        public static TestTableSnapshotInputFormat.TestTableSnapshotCounters valueOf(String name)
        +
        public static TestTableSnapshotInputFormat.TestTableSnapshotCounters valueOf(String name)
        Returns the enum constant of this type with the specified name. The string must match exactly an identifier used to declare an enum constant in this type. (Extraneous whitespace characters are http://git-wip-us.apache.org/repos/asf/hbase-site/blob/640333c3/testdevapidocs/org/apache/hadoop/hbase/mapreduce/TestTableSnapshotInputFormat.TestTableSnapshotMapper.html ---------------------------------------------------------------------- diff --git a/testdevapidocs/org/apache/hadoop/hbase/mapreduce/TestTableSnapshotInputFormat.TestTableSnapshotMapper.html b/testdevapidocs/org/apache/hadoop/hbase/mapreduce/TestTableSnapshotInputFormat.TestTableSnapshotMapper.html index 558d7d1..b60b3b2 100644 --- a/testdevapidocs/org/apache/hadoop/hbase/mapreduce/TestTableSnapshotInputFormat.TestTableSnapshotMapper.html +++ b/testdevapidocs/org/apache/hadoop/hbase/mapreduce/TestTableSnapshotInputFormat.TestTableSnapshotMapper.html @@ -123,7 +123,7 @@ var activeTableTab = "activeTableTab";


  • -
    public static class TestTableSnapshotInputFormat.TestTableSnapshotMapper
    +
    public static class TestTableSnapshotInputFormat.TestTableSnapshotMapper
     extends org.apache.hadoop.hbase.mapreduce.TableMapper<org.apache.hadoop.hbase.io.ImmutableBytesWritable,org.apache.hadoop.io.NullWritable>
  • @@ -216,7 +216,7 @@ extends org.apache.hadoop.hbase.mapreduce.TableMapper<org.apache.hadoop.hbase
  • @@ -233,7 +233,7 @@ extends org.apache.hadoop.hbase.mapreduce.TableMapper<org.apache.hadoop.hbase
    • map

      -
      protected void map(org.apache.hadoop.hbase.io.ImmutableBytesWritable key,
      +
      protected void map(org.apache.hadoop.hbase.io.ImmutableBytesWritable key,
                          org.apache.hadoop.hbase.client.Result value,
                          org.apache.hadoop.mapreduce.Mapper.Context context)
                   throws IOException,
      
      http://git-wip-us.apache.org/repos/asf/hbase-site/blob/640333c3/testdevapidocs/org/apache/hadoop/hbase/mapreduce/TestTableSnapshotInputFormat.TestTableSnapshotReducer.html
      ----------------------------------------------------------------------
      diff --git a/testdevapidocs/org/apache/hadoop/hbase/mapreduce/TestTableSnapshotInputFormat.TestTableSnapshotReducer.html b/testdevapidocs/org/apache/hadoop/hbase/mapreduce/TestTableSnapshotInputFormat.TestTableSnapshotReducer.html
      index d06fd60..5bf38f1 100644
      --- a/testdevapidocs/org/apache/hadoop/hbase/mapreduce/TestTableSnapshotInputFormat.TestTableSnapshotReducer.html
      +++ b/testdevapidocs/org/apache/hadoop/hbase/mapreduce/TestTableSnapshotInputFormat.TestTableSnapshotReducer.html
      @@ -118,7 +118,7 @@ var activeTableTab = "activeTableTab";
       


    -
    public static class TestTableSnapshotInputFormat.TestTableSnapshotReducer
    +
    public static class TestTableSnapshotInputFormat.TestTableSnapshotReducer
     extends org.apache.hadoop.mapreduce.Reducer<org.apache.hadoop.hbase.io.ImmutableBytesWritable,org.apache.hadoop.io.NullWritable,org.apache.hadoop.io.NullWritable,org.apache.hadoop.io.NullWritable>
  • @@ -234,7 +234,7 @@ extends org.apache.hadoop.mapreduce.Reducer<org.apache.hadoop.hbase.io.Immuta
  • @@ -251,7 +251,7 @@ extends org.apache.hadoop.mapreduce.Reducer<org.apache.hadoop.hbase.io.Immuta
  • @@ -268,7 +268,7 @@ extends org.apache.hadoop.mapreduce.Reducer<org.apache.hadoop.hbase.io.Immuta
    • reduce

      -
      protected void reduce(org.apache.hadoop.hbase.io.ImmutableBytesWritable key,
      +
      protected void reduce(org.apache.hadoop.hbase.io.ImmutableBytesWritable key,
                             Iterable<org.apache.hadoop.io.NullWritable> values,
                             org.apache.hadoop.mapreduce.Reducer.Context context)
                      throws IOException,
      @@ -288,7 +288,7 @@ extends org.apache.hadoop.mapreduce.Reducer<org.apache.hadoop.hbase.io.Immuta
       
      • cleanup

        -
        protected void cleanup(org.apache.hadoop.mapreduce.Reducer.Context context)
        +
        protected void cleanup(org.apache.hadoop.mapreduce.Reducer.Context context)
                         throws IOException,
                                InterruptedException
        http://git-wip-us.apache.org/repos/asf/hbase-site/blob/640333c3/testdevapidocs/org/apache/hadoop/hbase/mapreduce/TestTableSnapshotInputFormat.html ---------------------------------------------------------------------- diff --git a/testdevapidocs/org/apache/hadoop/hbase/mapreduce/TestTableSnapshotInputFormat.html b/testdevapidocs/org/apache/hadoop/hbase/mapreduce/TestTableSnapshotInputFormat.html index 28518f5..6c2b4a9 100644 --- a/testdevapidocs/org/apache/hadoop/hbase/mapreduce/TestTableSnapshotInputFormat.html +++ b/testdevapidocs/org/apache/hadoop/hbase/mapreduce/TestTableSnapshotInputFormat.html @@ -114,7 +114,7 @@ var activeTableTab = "activeTableTab";


      • -
        public class TestTableSnapshotInputFormat
        +
        public class TestTableSnapshotInputFormat
         extends TableSnapshotInputFormatTestBase
      @@ -166,14 +166,18 @@ extends bbb  +private static org.apache.commons.logging.Log +LOG  + + org.junit.rules.TestName name  - + org.junit.rules.TestRule timeout  - + private static byte[] yyy  @@ -318,13 +322,22 @@ extends + + +
        +
      • +

        LOG

        +
        private static final org.apache.commons.logging.Log LOG
        +
      • +
      • timeout

        -
        public final org.junit.rules.TestRule timeout
        +
        public final org.junit.rules.TestRule timeout
      @@ -333,7 +346,7 @@ extends
    • bbb

      -
      private static final byte[] bbb
      +
      private static final byte[] bbb
    @@ -342,7 +355,7 @@ extends
  • yyy

    -
    private static final byte[] yyy
    +
    private static final byte[] yyy
  • @@ -351,7 +364,7 @@ extends
  • name

    -
    public org.junit.rules.TestName name
    +
    public org.junit.rules.TestName name
  • @@ -368,7 +381,7 @@ extends
  • TestTableSnapshotInputFormat

    -
    public TestTableSnapshotInputFormat()
    +
    public TestTableSnapshotInputFormat()
  • @@ -385,7 +398,7 @@ extends
  • getStartRow

    -
    protected byte[] getStartRow()
    +
    protected byte[] getStartRow()
    Specified by:
    getStartRow in class TableSnapshotInputFormatTestBase
    @@ -398,7 +411,7 @@ extends
  • getEndRow

    -
    protected byte[] getEndRow()
    +
    protected byte[] getEndRow()
    Specified by:
    getEndRow in class TableSnapshotInputFormatTestBase
    @@ -411,7 +424,7 @@ extends
  • tearDown

    -
    public void tearDown()
    +
    public void tearDown()
                   throws Exception
    Throws:
    @@ -425,7 +438,7 @@ extends
  • testGetBestLocations

    -
    public void testGetBestLocations()
    +
    public void testGetBestLocations()
                               throws IOException
    Throws:
    @@ -439,7 +452,7 @@ extends
  • testInitTableSnapshotMapperJobConfig

    -
    public void testInitTableSnapshotMapperJobConfig()
    +
    public void testInitTableSnapshotMapperJobConfig()
                                               throws Exception
    Throws:
    @@ -453,7 +466,7 @@ extends
  • testRestoreSnapshotDoesNotCreateBackRefLinksInit

    -
    public void testRestoreSnapshotDoesNotCreateBackRefLinksInit(org.apache.hadoop.hbase.TableName tableName,
    +
    public void testRestoreSnapshotDoesNotCreateBackRefLinksInit(org.apache.hadoop.hbase.TableName tableName,
                                                                  String snapshotName,
                                                                  org.apache.hadoop.fs.Path tmpTableDir)
                                                           throws Exception
    @@ -471,7 +484,7 @@ extends
  • testWithMockedMapReduce

    -
    public void testWithMockedMapReduce(HBaseTestingUtility util,
    +
    public void testWithMockedMapReduce(HBaseTestingUtility util,
                                         String snapshotName,
                                         int numRegions,
                                         int expectedNumSplits)
    @@ -490,7 +503,7 @@ extends 
     
  • blockUntilSplitFinished

    -
    public static void blockUntilSplitFinished(HBaseTestingUtility util,
    +
    public static void blockUntilSplitFinished(HBaseTestingUtility util,
                                                org.apache.hadoop.hbase.TableName tableName,
                                                int expectedRegionSize)
                                         throws Exception
    @@ -506,7 +519,7 @@ extends
  • testNoDuplicateResultsWhenSplitting

    -
    public void testNoDuplicateResultsWhenSplitting()
    +
    public void testNoDuplicateResultsWhenSplitting()
                                              throws Exception
    Throws:
    @@ -520,7 +533,7 @@ extends
  • verifyWithMockedMapReduce

    -
    private void verifyWithMockedMapReduce(org.apache.hadoop.mapreduce.Job job,
    +
    private void verifyWithMockedMapReduce(org.apache.hadoop.mapreduce.Job job,
                                            int numRegions,
                                            int expectedNumSplits,
                                            byte[] startRow,
    @@ -540,7 +553,7 @@ extends 
     
  • testWithMapReduceImpl

    -
    protected void testWithMapReduceImpl(HBaseTestingUtility util,
    +
    protected void testWithMapReduceImpl(HBaseTestingUtility util,
                                          org.apache.hadoop.hbase.TableName tableName,
                                          String snapshotName,
                                          org.apache.hadoop.fs.Path tableDir,
    @@ -562,7 +575,7 @@ extends 
     
  • doTestWithMapReduce

    -
    public static void doTestWithMapReduce(HBaseTestingUtility util,
    +
    public static void doTestWithMapReduce(HBaseTestingUtility util,
                                            org.apache.hadoop.hbase.TableName tableName,
                                            String snapshotName,
                                            byte[] startRow,
    
    http://git-wip-us.apache.org/repos/asf/hbase-site/blob/640333c3/testdevapidocs/org/apache/hadoop/hbase/package-tree.html
    ----------------------------------------------------------------------
    diff --git a/testdevapidocs/org/apache/hadoop/hbase/package-tree.html b/testdevapidocs/org/apache/hadoop/hbase/package-tree.html
    index 82d8979..f4b1695 100644
    --- a/testdevapidocs/org/apache/hadoop/hbase/package-tree.html
    +++ b/testdevapidocs/org/apache/hadoop/hbase/package-tree.html
    @@ -542,15 +542,15 @@
     
    
    http://git-wip-us.apache.org/repos/asf/hbase-site/blob/640333c3/testdevapidocs/org/apache/hadoop/hbase/procedure2/package-tree.html
    ----------------------------------------------------------------------
    diff --git a/testdevapidocs/org/apache/hadoop/hbase/procedure2/package-tree.html b/testdevapidocs/org/apache/hadoop/hbase/procedure2/package-tree.html
    index f73ba8e..b97ba43 100644
    --- a/testdevapidocs/org/apache/hadoop/hbase/procedure2/package-tree.html
    +++ b/testdevapidocs/org/apache/hadoop/hbase/procedure2/package-tree.html
    @@ -205,8 +205,8 @@
     


  • -
    static class SnapshotTestingUtils.SnapshotMock.RegionData
    +
    static class SnapshotTestingUtils.SnapshotMock.RegionData
     extends Object
  • @@ -194,7 +194,7 @@ extends
  • hri

    -
    public org.apache.hadoop.hbase.HRegionInfo hri
    +
    public org.apache.hadoop.hbase.HRegionInfo hri
  • @@ -203,7 +203,7 @@ extends
  • tableDir

    -
    public org.apache.hadoop.fs.Path tableDir
    +
    public org.apache.hadoop.fs.Path tableDir
  • @@ -212,7 +212,7 @@ extends
  • files

    -
    public org.apache.hadoop.fs.Path[] files
    +
    public org.apache.hadoop.fs.Path[] files
  • @@ -229,7 +229,7 @@ extends
  • RegionData

    -
    public RegionData(org.apache.hadoop.fs.Path tableDir,
    +
    public RegionData(org.apache.hadoop.fs.Path tableDir,
                       org.apache.hadoop.hbase.HRegionInfo hri,
                       int nfiles)
  • http://git-wip-us.apache.org/repos/asf/hbase-site/blob/640333c3/testdevapidocs/org/apache/hadoop/hbase/snapshot/SnapshotTestingUtils.SnapshotMock.SnapshotBuilder.html ---------------------------------------------------------------------- diff --git a/testdevapidocs/org/apache/hadoop/hbase/snapshot/SnapshotTestingUtils.SnapshotMock.SnapshotBuilder.html b/testdevapidocs/org/apache/hadoop/hbase/snapshot/SnapshotTestingUtils.SnapshotMock.SnapshotBuilder.html index ee1bd88..4028f97 100644 --- a/testdevapidocs/org/apache/hadoop/hbase/snapshot/SnapshotTestingUtils.SnapshotMock.SnapshotBuilder.html +++ b/testdevapidocs/org/apache/hadoop/hbase/snapshot/SnapshotTestingUtils.SnapshotMock.SnapshotBuilder.html @@ -113,7 +113,7 @@ var activeTableTab = "activeTableTab";


  • -
    public static class SnapshotTestingUtils.SnapshotMock.SnapshotBuilder
    +
    public static class SnapshotTestingUtils.SnapshotMock.SnapshotBuilder
     extends Object
  • @@ -286,7 +286,7 @@ extends
  • tableRegions

    -
    private final SnapshotTestingUtils.SnapshotMock.RegionData[] tableRegions
    +
    private final SnapshotTestingUtils.SnapshotMock.RegionData[] tableRegions
  • @@ -295,7 +295,7 @@ extends
  • desc

    -
    private final org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription desc
    +
    private final org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription desc
  • @@ -304,7 +304,7 @@ extends
  • htd

    -
    private final org.apache.hadoop.hbase.HTableDescriptor htd
    +
    private final org.apache.hadoop.hbase.HTableDescriptor htd
  • @@ -313,7 +313,7 @@ extends
  • conf

    -
    private final org.apache.hadoop.conf.Configuration conf
    +
    private final org.apache.hadoop.conf.Configuration conf
  • @@ -322,7 +322,7 @@ extends
  • fs

    -
    private final org.apache.hadoop.fs.FileSystem fs
    +
    private final org.apache.hadoop.fs.FileSystem fs
  • @@ -331,7 +331,7 @@ extends
  • rootDir

    -
    private final org.apache.hadoop.fs.Path rootDir
    +
    private final org.apache.hadoop.fs.Path rootDir
  • @@ -340,7 +340,7 @@ extends
  • snapshotDir

    -
    private org.apache.hadoop.fs.Path snapshotDir
    +
    private org.apache.hadoop.fs.Path snapshotDir
  • @@ -349,7 +349,7 @@ extends
  • snapshotted

    -
    private int snapshotted
    +
    private int snapshotted
  • @@ -366,7 +366,7 @@ extends
  • SnapshotBuilder

    -
    public SnapshotBuilder(org.apache.hadoop.conf.Configuration conf,
    +
    public SnapshotBuilder(org.apache.hadoop.conf.Configuration conf,
                            org.apache.hadoop.fs.FileSystem fs,
                            org.apache.hadoop.fs.Path rootDir,
                            org.apache.hadoop.hbase.HTableDescriptor htd,
    @@ -393,7 +393,7 @@ extends 
     
  • getTableDescriptor

    -
    public org.apache.hadoop.hbase.HTableDescriptor getTableDescriptor()
    +
    public org.apache.hadoop.hbase.HTableDescriptor getTableDescriptor()
  • @@ -402,7 +402,7 @@ extends
  • getSnapshotDescription

    -
    public org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription getSnapshotDescription()
    +
    public org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription getSnapshotDescription()
  • @@ -411,7 +411,7 @@ extends
  • getSnapshotsDir

    -
    public org.apache.hadoop.fs.Path getSnapshotsDir()
    +
    public org.apache.hadoop.fs.Path getSnapshotsDir()
  • @@ -420,7 +420,7 @@ extends
  • addRegion

    -
    public org.apache.hadoop.fs.Path[] addRegion()
    +
    public org.apache.hadoop.fs.Path[] addRegion()
                                           throws IOException
    Throws:
    @@ -434,7 +434,7 @@ extends
  • addRegionV1

    -
    public org.apache.hadoop.fs.Path[] addRegionV1()
    +
    public org.apache.hadoop.fs.Path[] addRegionV1()
                                             throws IOException
    Throws:
    @@ -448,7 +448,7 @@ extends
  • addRegionV2

    -
    public org.apache.hadoop.fs.Path[] addRegionV2()
    +
    public org.apache.hadoop.fs.Path[] addRegionV2()
                                             throws IOException
    Throws:
    @@ -462,7 +462,7 @@ extends
  • addRegion

    -
    private org.apache.hadoop.fs.Path[] addRegion(org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription desc)
    +
    private org.apache.hadoop.fs.Path[] addRegion(org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription desc)
                                            throws IOException
    Throws:
    @@ -476,7 +476,7 @@ extends
  • corruptFile

    -
    private void corruptFile(org.apache.hadoop.fs.Path p)
    +
    private void corruptFile(org.apache.hadoop.fs.Path p)
                       throws IOException
    Throws:
    @@ -490,7 +490,7 @@ extends
  • corruptOneRegionManifest

    -
    public void corruptOneRegionManifest()
    +
    public void corruptOneRegionManifest()
                                   throws IOException
    Corrupt one region-manifest file
    @@ -505,7 +505,7 @@ extends
  • missOneRegionSnapshotFile

    -
    public void missOneRegionSnapshotFile()
    +
    public void missOneRegionSnapshotFile()
                                    throws IOException
    Throws:
    @@ -519,7 +519,7 @@ extends
  • corruptDataManifest

    -
    public void corruptDataManifest()
    +
    public void corruptDataManifest()
                              throws IOException
    Corrupt data-manifest file
    @@ -534,7 +534,7 @@ extends
  • commit

    -
    public org.apache.hadoop.fs.Path commit()
    +
    public org.apache.hadoop.fs.Path commit()
                                      throws IOException
    Throws:
    @@ -548,7 +548,7 @@ extends
  • consolidate

    -
    public void consolidate()
    +
    public void consolidate()
                      throws IOException
    Throws: