Return-Path: X-Original-To: apmail-hbase-commits-archive@www.apache.org Delivered-To: apmail-hbase-commits-archive@www.apache.org Received: from mail.apache.org (hermes.apache.org [140.211.11.3]) by minotaur.apache.org (Postfix) with SMTP id 4842918BAF for ; Mon, 1 Feb 2016 16:57:44 +0000 (UTC) Received: (qmail 30880 invoked by uid 500); 1 Feb 2016 16:57:00 -0000 Delivered-To: apmail-hbase-commits-archive@hbase.apache.org Received: (qmail 30780 invoked by uid 500); 1 Feb 2016 16:57:00 -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 28033 invoked by uid 99); 1 Feb 2016 16:56:58 -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; Mon, 01 Feb 2016 16:56:58 +0000 Received: by git1-us-west.apache.org (ASF Mail Server at git1-us-west.apache.org, from userid 33) id 7A1A0DFCDD; Mon, 1 Feb 2016 16:56:58 +0000 (UTC) Content-Type: text/plain; charset="us-ascii" MIME-Version: 1.0 Content-Transfer-Encoding: 7bit From: misty@apache.org To: commits@hbase.apache.org Date: Mon, 01 Feb 2016 16:57:33 -0000 Message-Id: <56505cc3876e4392a13311183e82b188@git.apache.org> In-Reply-To: <14392ad1c5b44bc388d1159e43dc3416@git.apache.org> References: <14392ad1c5b44bc388d1159e43dc3416@git.apache.org> X-Mailer: ASF-Git Admin Mailer Subject: [37/51] [partial] hbase-site git commit: Published site at 2cc48e039d1f800832ac8880bbc820982e0ac8a5. http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a7e5a8ce/devapidocs/org/apache/hadoop/hbase/client/Scan.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/client/Scan.html b/devapidocs/org/apache/hadoop/hbase/client/Scan.html index 3d53918..61834a9 100644 --- a/devapidocs/org/apache/hadoop/hbase/client/Scan.html +++ b/devapidocs/org/apache/hadoop/hbase/client/Scan.html @@ -1088,7 +1088,7 @@ public static final 
  • Scan

    -
    public Scan(Get get)
    +
    public Scan(Get get)
    Builds a scan object with the same specs as get.
    Parameters:
    get - get to model scan after
  • @@ -1107,7 +1107,7 @@ public static final 
  • isGetScan

    -
    public boolean isGetScan()
    +
    public boolean isGetScan()
  • @@ -1116,7 +1116,7 @@ public static final 
  • isStartRowAndEqualsStopRow

    -
    private boolean isStartRowAndEqualsStopRow()
    +
    private boolean isStartRowAndEqualsStopRow()
  • @@ -1125,7 +1125,7 @@ public static final 
  • addFamily

    -
    public Scan addFamily(byte[] family)
    +
    public Scan addFamily(byte[] family)
    Get all columns from the specified family.

    Overrides previous calls to addColumn for this family.

    @@ -1139,7 +1139,7 @@ public static final 
  • addColumn

    -
    public Scan addColumn(byte[] family,
    +
    public Scan addColumn(byte[] family,
                  byte[] qualifier)
    Get the column from the specified family with the specified qualifier.

    @@ -1154,7 +1154,7 @@ public static final 

  • setTimeRange

    -
    public Scan setTimeRange(long minStamp,
    +
    public Scan setTimeRange(long minStamp,
                     long maxStamp)
                       throws IOException
    Get versions of columns only within the specified timestamp range, @@ -1174,7 +1174,7 @@ public static final 
  • setTimeStamp

    -
    public Scan setTimeStamp(long timestamp)
    +
    public Scan setTimeStamp(long timestamp)
                       throws IOException
    Get versions of columns with the specified timestamp. Note, default maximum versions to return is 1. If your time range spans more than one version @@ -1193,7 +1193,7 @@ public static final 
  • setColumnFamilyTimeRange

    -
    public Scan setColumnFamilyTimeRange(byte[] cf,
    +
    public Scan setColumnFamilyTimeRange(byte[] cf,
                                 long minStamp,
                                 long maxStamp)
    Description copied from class: Query
    @@ -1215,7 +1215,7 @@ public static final 
  • setStartRow

    -
    public Scan setStartRow(byte[] startRow)
    +
    public Scan setStartRow(byte[] startRow)
    Set the start row of the scan.

    If the specified row does not exist, the Scanner will start from the @@ -1230,7 +1230,7 @@ public static final 

  • setStopRow

    -
    public Scan setStopRow(byte[] stopRow)
    +
    public Scan setStopRow(byte[] stopRow)
    Set the stop row of the scan.
    Parameters:
    stopRow - row to end at (exclusive)

    @@ -1248,7 +1248,7 @@ public static final 

  • setRowPrefixFilter

    -
    public Scan setRowPrefixFilter(byte[] rowPrefix)
    +
    public Scan setRowPrefixFilter(byte[] rowPrefix)

    Set a filter (using stopRow and startRow) so the result set only contains rows where the rowKey starts with the specified prefix.

    This is a utility method that converts the desired rowPrefix into the appropriate values @@ -1266,7 +1266,7 @@ public static final 

  • calculateTheClosestNextRowKeyForPrefix

    -
    private byte[] calculateTheClosestNextRowKeyForPrefix(byte[] rowKeyPrefix)
    +
    private byte[] calculateTheClosestNextRowKeyForPrefix(byte[] rowKeyPrefix)

    When scanning for a prefix the scan should stop immediately after the the last row that has the specified prefix. This method calculates the closest next rowKey immediately following the given rowKeyPrefix.

    @@ -1289,7 +1289,7 @@ public static final 
  • setMaxVersions

    -
    public Scan setMaxVersions()
    +
    public Scan setMaxVersions()
    Get all available versions.
    Returns:
    this
  • @@ -1300,7 +1300,7 @@ public static final 
  • setMaxVersions

    -
    public Scan setMaxVersions(int maxVersions)
    +
    public Scan setMaxVersions(int maxVersions)
    Get up to the specified number of versions of each column.
    Parameters:
    maxVersions - maximum versions for each column
    Returns:
    this
    @@ -1312,7 +1312,7 @@ public static final 
  • setBatch

    -
    public Scan setBatch(int batch)
    +
    public Scan setBatch(int batch)
    Set the maximum number of values to return for each call to next()
    Parameters:
    batch - the maximum number of values
  • @@ -1323,7 +1323,7 @@ public static final 
  • setMaxResultsPerColumnFamily

    -
    public Scan setMaxResultsPerColumnFamily(int limit)
    +
    public Scan setMaxResultsPerColumnFamily(int limit)
    Set the maximum number of values to return per row per Column Family
    Parameters:
    limit - the maximum number of values returned / row / CF
  • @@ -1334,7 +1334,7 @@ public static final 
  • setRowOffsetPerColumnFamily

    -
    public Scan setRowOffsetPerColumnFamily(int offset)
    +
    public Scan setRowOffsetPerColumnFamily(int offset)
    Set offset for the row per Column Family.
    Parameters:
    offset - is the number of kvs that will be skipped.
  • @@ -1345,7 +1345,7 @@ public static final 
  • setCaching

    -
    public Scan setCaching(int caching)
    +
    public Scan setCaching(int caching)
    Set the number of rows for caching that will be passed to scanners. If not set, the Configuration setting HConstants.HBASE_CLIENT_SCANNER_CACHING will apply. @@ -1359,7 +1359,7 @@ public static final 
  • getMaxResultSize

    -
    public long getMaxResultSize()
    +
    public long getMaxResultSize()
    Returns:
    the maximum result size in bytes. See setMaxResultSize(long)
  • @@ -1369,7 +1369,7 @@ public static final 
  • setMaxResultSize

    -
    public Scan setMaxResultSize(long maxResultSize)
    +
    public Scan setMaxResultSize(long maxResultSize)
    Set the maximum result size. The default is -1; this means that no specific maximum result size will be set for this scan, and the global configured value will be used instead. (Defaults to unlimited).
    @@ -1382,7 +1382,7 @@ public static final 
  • setFilter

    -
    public Scan setFilter(Filter filter)
    +
    public Scan setFilter(Filter filter)
    Description copied from class: Query
    Apply the specified server-side filter when performing the Query. Only Filter.filterKeyValue(Cell) is called AFTER all tests @@ -1400,7 +1400,7 @@ public static final 
  • setFamilyMap

    -
    public Scan setFamilyMap(Map<byte[],NavigableSet<byte[]>> familyMap)
    +
    public Scan setFamilyMap(Map<byte[],NavigableSet<byte[]>> familyMap)
    Setting the familyMap
    Parameters:
    familyMap - map of family to qualifier
    Returns:
    this
    @@ -1412,7 +1412,7 @@ public static final 
  • getFamilyMap

    -
    public Map<byte[],NavigableSet<byte[]>> getFamilyMap()
    +
    public Map<byte[],NavigableSet<byte[]>> getFamilyMap()
    Getting the familyMap
    Returns:
    familyMap
  • @@ -1423,7 +1423,7 @@ public static final 
  • numFamilies

    -
    public int numFamilies()
    +
    public int numFamilies()
    Returns:
    the number of families in familyMap
  • @@ -1433,7 +1433,7 @@ public static final 
  • hasFamilies

    -
    public boolean hasFamilies()
    +
    public boolean hasFamilies()
    Returns:
    true if familyMap is non empty, false otherwise
  • @@ -1443,7 +1443,7 @@ public static final 
  • getFamilies

    -
    public byte[][] getFamilies()
    +
    public byte[][] getFamilies()
    Returns:
    the keys of the familyMap
  • @@ -1453,7 +1453,7 @@ public static final 
  • getStartRow

    -
    public byte[] getStartRow()
    +
    public byte[] getStartRow()
    Returns:
    the startrow
  • @@ -1463,7 +1463,7 @@ public static final 
  • getStopRow

    -
    public byte[] getStopRow()
    +
    public byte[] getStopRow()
    Returns:
    the stoprow
  • @@ -1473,7 +1473,7 @@ public static final 
  • getMaxVersions

    -
    public int getMaxVersions()
    +
    public int getMaxVersions()
    Returns:
    the max number of versions to fetch
  • @@ -1483,7 +1483,7 @@ public static final 
  • getBatch

    -
    public int getBatch()
    +
    public int getBatch()
    Returns:
    maximum number of values to return for a single call to next()
  • @@ -1493,7 +1493,7 @@ public static final 
  • getMaxResultsPerColumnFamily

    -
    public int getMaxResultsPerColumnFamily()
    +
    public int getMaxResultsPerColumnFamily()
    Returns:
    maximum number of values to return per row per CF
  • @@ -1503,7 +1503,7 @@ public static final 
  • getRowOffsetPerColumnFamily

    -
    public int getRowOffsetPerColumnFamily()
    +
    public int getRowOffsetPerColumnFamily()
    Method for retrieving the scan's offset per row per column family (#kvs to be skipped)
    Returns:
    row offset
    @@ -1515,7 +1515,7 @@ public static final 
  • getCaching

    -
    public int getCaching()
    +
    public int getCaching()
    Returns:
    caching the number of rows fetched when calling next on a scanner
  • @@ -1525,7 +1525,7 @@ public static final 
  • getTimeRange

    -
    public TimeRange getTimeRange()
    +
    public TimeRange getTimeRange()
    Returns:
    TimeRange
  • @@ -1535,7 +1535,7 @@ public static final 
  • getFilter

    -
    public Filter getFilter()
    +
    public Filter getFilter()
    Overrides:
    getFilter in class Query
    @@ -1548,7 +1548,7 @@ public static final 
  • hasFilter

    -
    public boolean hasFilter()
    +
    public boolean hasFilter()
    Returns:
    true is a filter has been specified, false if not
  • @@ -1558,7 +1558,7 @@ public static final 
  • setCacheBlocks

    -
    public Scan setCacheBlocks(boolean cacheBlocks)
    +
    public Scan setCacheBlocks(boolean cacheBlocks)
    Set whether blocks should be cached for this Scan.

    This is true by default. When true, default settings of the table and @@ -1574,7 +1574,7 @@ public static final 

  • getCacheBlocks

    -
    public boolean getCacheBlocks()
    +
    public boolean getCacheBlocks()
    Get whether blocks should be cached for this Scan.
    Returns:
    true if default caching should be used, false if blocks should not be cached
    @@ -1586,7 +1586,7 @@ public static final 
  • setReversed

    -
    public Scan setReversed(boolean reversed)
    +
    public Scan setReversed(boolean reversed)
    Set whether this scan is a reversed one

    This is false by default which means forward(normal) scan.

    @@ -1600,7 +1600,7 @@ public static final 
  • isReversed

    -
    public boolean isReversed()
    +
    public boolean isReversed()
    Get whether this scan is a reversed one.
    Returns:
    true if backward scan, false if forward(default) scan
  • @@ -1611,7 +1611,7 @@ public static final 
  • setAllowPartialResults

    -
    public Scan setAllowPartialResults(boolean allowPartialResults)
    +
    public Scan setAllowPartialResults(boolean allowPartialResults)
    Setting whether the caller wants to see the partial results that may be returned from the server. By default this value is false and the complete results will be assembled client side before being delivered to the caller.
    @@ -1625,7 +1625,7 @@ public static final 
  • getAllowPartialResults

    -
    public boolean getAllowPartialResults()
    +
    public boolean getAllowPartialResults()
    Returns:
    true when the constructor of this scan understands that the results they will see may only represent a partial portion of a row. The entire row would be retrieved by subsequent calls to ResultScanner.next()
    @@ -1637,7 +1637,7 @@ public static final 
  • setLoadColumnFamiliesOnDemand

    -
    public Scan setLoadColumnFamiliesOnDemand(boolean value)
    +
    public Scan setLoadColumnFamiliesOnDemand(boolean value)
    Set the value indicating whether loading CFs on demand should be allowed (cluster default is false). On-demand CF loading doesn't load column families until necessary, e.g. if you filter on one column, the other column family data will be loaded only for the rows @@ -1660,7 +1660,7 @@ public static final 
  • getLoadColumnFamiliesOnDemandValue

    -
    public Boolean getLoadColumnFamiliesOnDemandValue()
    +
    public Boolean getLoadColumnFamiliesOnDemandValue()
    Get the raw loadColumnFamiliesOnDemand setting; if it's not set, can be null.
  • @@ -1670,7 +1670,7 @@ public static final 
  • doLoadColumnFamiliesOnDemand

    -
    public boolean doLoadColumnFamiliesOnDemand()
    +
    public boolean doLoadColumnFamiliesOnDemand()
    Get the logical value indicating whether on-demand CF loading should be allowed.
  • @@ -1680,7 +1680,7 @@ public static final 
  • getFingerprint

    -
    public Map<String,ObjectgetFingerprint()
    +
    public Map<String,ObjectgetFingerprint()
    Compile the table and column family (i.e. schema) information into a String. Useful for parsing and aggregation by debugging, logging, and administration tools.
    @@ -1696,7 +1696,7 @@ public static final 
  • toMap

    -
    public Map<String,ObjecttoMap(int maxCols)
    +
    public Map<String,ObjecttoMap(int maxCols)
    Compile the details beyond the scope of getFingerprint (row, columns, timestamps, etc.) into a Map along with the fingerprinted information. Useful for debugging, logging, and administration tools.
    @@ -1713,7 +1713,7 @@ public static final 
  • setRaw

    -
    public Scan setRaw(boolean raw)
    +
    public Scan setRaw(boolean raw)
    Enable/disable "raw" mode for this scan. If "raw" is enabled the scan will return all delete marker and deleted rows that have not @@ -1730,7 +1730,7 @@ public static final 
  • isRaw

    -
    public boolean isRaw()
    +
    public boolean isRaw()
    Returns:
    True if this Scan is in "raw" mode.
  • @@ -1740,7 +1740,7 @@ public static final 
  • setSmall

    -
    public Scan setSmall(boolean small)
    +
    public Scan setSmall(boolean small)
    Set whether this scan is a small scan

    Small scan should use pread and big scan can use seek + read @@ -1766,7 +1766,7 @@ public static final 

  • isSmall

    -
    public boolean isSmall()
    +
    public boolean isSmall()
    Get whether this scan is a small scan
    Returns:
    true if small scan
  • @@ -1777,7 +1777,7 @@ public static final 
  • setAttribute

    -
    public Scan setAttribute(String name,
    +
    public Scan setAttribute(String name,
                     byte[] value)
    Description copied from interface: Attributes
    Sets an attribute. @@ -1797,7 +1797,7 @@ public static final 
  • setId

    -
    public Scan setId(String id)
    +
    public Scan setId(String id)
    Description copied from class: OperationWithAttributes
    This method allows you to set an identifier on an operation. The original motivation for this was to allow the identifier to be used in slow query @@ -1816,7 +1816,7 @@ public static final 
  • setAuthorizations

    -
    public Scan setAuthorizations(Authorizations authorizations)
    +
    public Scan setAuthorizations(Authorizations authorizations)
    Description copied from class: Query
    Sets the authorizations to be used by this Query
    @@ -1831,7 +1831,7 @@ public static final 
  • setACL

    -
    public Scan setACL(Map<String,Permission> perms)
    +
    public Scan setACL(Map<String,Permission> perms)
    Overrides:
    setACL in class Query
    @@ -1844,7 +1844,7 @@ public static final 
  • setACL

    -
    public Scan setACL(String user,
    +
    public Scan setACL(String user,
               Permission perms)
    Overrides:
    @@ -1858,7 +1858,7 @@ public static final 
  • setConsistency

    -
    public Scan setConsistency(Consistency consistency)
    +
    public Scan setConsistency(Consistency consistency)
    Description copied from class: Query
    Sets the consistency level for this operation
    @@ -1873,7 +1873,7 @@ public static final 
  • setReplicaId

    -
    public Scan setReplicaId(int Id)
    +
    public Scan setReplicaId(int Id)
    Description copied from class: Query
    Specify region replica id where Query will fetch data from. Use this together with Query.setConsistency(Consistency) passing Consistency.TIMELINE to read data from @@ -1891,7 +1891,7 @@ public static final 
  • setIsolationLevel

    -
    public Scan setIsolationLevel(IsolationLevel level)
    +
    public Scan setIsolationLevel(IsolationLevel level)
    Description copied from class: Query
    Set the isolation level for this query. If the isolation level is set to READ_UNCOMMITTED, then @@ -1913,7 +1913,7 @@ public static final 
  • setScanMetricsEnabled

    -
    public Scan setScanMetricsEnabled(boolean enabled)
    +
    public Scan setScanMetricsEnabled(boolean enabled)
    Enable collection of ScanMetrics. For advanced users.
    Parameters:
    enabled - Set to true to enable accumulating scan metrics
  • @@ -1924,7 +1924,7 @@ public static final 
  • isScanMetricsEnabled

    -
    public boolean isScanMetricsEnabled()
    +
    public boolean isScanMetricsEnabled()
    Returns:
    True if collection of scan metrics is enabled. For advanced users.
  • @@ -1934,7 +1934,7 @@ public static final 
  • getScanMetrics

    -
    public ScanMetrics getScanMetrics()
    +
    public ScanMetrics getScanMetrics()
    Returns:
    Metrics on this Scan, if metrics were enabled.
    See Also:
    setScanMetricsEnabled(boolean)
  • @@ -1944,7 +1944,7 @@ public static final 
  • isAsyncPrefetch

    -
    public Boolean isAsyncPrefetch()
    +
    public Boolean isAsyncPrefetch()
  • @@ -1953,7 +1953,7 @@ public static final 
  • setAsyncPrefetch

    -
    public Scan setAsyncPrefetch(boolean asyncPrefetch)
    +
    public Scan setAsyncPrefetch(boolean asyncPrefetch)
  • http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a7e5a8ce/devapidocs/org/apache/hadoop/hbase/client/class-use/IsolationLevel.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/client/class-use/IsolationLevel.html b/devapidocs/org/apache/hadoop/hbase/client/class-use/IsolationLevel.html index 38d84c2..567e96b 100644 --- a/devapidocs/org/apache/hadoop/hbase/client/class-use/IsolationLevel.html +++ b/devapidocs/org/apache/hadoop/hbase/client/class-use/IsolationLevel.html @@ -168,7 +168,19 @@ the order they are declared.
  • long -Region.getReadpoint(IsolationLevel isolationLevel)  +Region.getReadpoint(IsolationLevel isolationLevel) +
    Deprecated.  +
    Since 1.2.0. Use Region.getReadPoint(IsolationLevel) instead.
    +
    + + + +long +HRegion.getReadPoint(IsolationLevel isolationLevel)  + + +long +Region.getReadPoint(IsolationLevel isolationLevel)  http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a7e5a8ce/devapidocs/org/apache/hadoop/hbase/client/class-use/Mutation.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/client/class-use/Mutation.html b/devapidocs/org/apache/hadoop/hbase/client/class-use/Mutation.html index 225c854..3b76647 100644 --- a/devapidocs/org/apache/hadoop/hbase/client/class-use/Mutation.html +++ b/devapidocs/org/apache/hadoop/hbase/client/class-use/Mutation.html @@ -701,8 +701,8 @@ Input/OutputFormats, a table indexing MapReduce job, and utility methods.
  • ByteArrayComparable comparator, Mutation mutation, boolean writeToWAL) -
    Atomically checks if a row/family/qualifier value matches the expected val - If it does, it performs the row mutations.
    +
    Atomically checks if a row/family/qualifier value matches the expected value and if it does, + it performs the mutation.
    http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a7e5a8ce/devapidocs/org/apache/hadoop/hbase/client/class-use/RowMutations.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/client/class-use/RowMutations.html b/devapidocs/org/apache/hadoop/hbase/client/class-use/RowMutations.html index b7d9200..8a2b2e0 100644 --- a/devapidocs/org/apache/hadoop/hbase/client/class-use/RowMutations.html +++ b/devapidocs/org/apache/hadoop/hbase/client/class-use/RowMutations.html @@ -191,8 +191,8 @@ service.
  • ByteArrayComparable comparator, RowMutations mutations, boolean writeToWAL) -
    Atomically checks if a row/family/qualifier value matches the expected val - If it does, it performs the row mutations.
    +
    Atomically checks if a row/family/qualifier value matches the expected values and if it does, + it performs the row mutations.
    http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a7e5a8ce/devapidocs/org/apache/hadoop/hbase/client/package-tree.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/client/package-tree.html b/devapidocs/org/apache/hadoop/hbase/client/package-tree.html index bc1ab25..3aebd36 100644 --- a/devapidocs/org/apache/hadoop/hbase/client/package-tree.html +++ b/devapidocs/org/apache/hadoop/hbase/client/package-tree.html @@ -389,12 +389,12 @@ http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a7e5a8ce/devapidocs/org/apache/hadoop/hbase/coprocessor/example/ZooKeeperScanPolicyObserver.ZKWatcher.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/coprocessor/example/ZooKeeperScanPolicyObserver.ZKWatcher.html b/devapidocs/org/apache/hadoop/hbase/coprocessor/example/ZooKeeperScanPolicyObserver.ZKWatcher.html index bd6bfda..20f3650 100644 --- a/devapidocs/org/apache/hadoop/hbase/coprocessor/example/ZooKeeperScanPolicyObserver.ZKWatcher.html +++ b/devapidocs/org/apache/hadoop/hbase/coprocessor/example/ZooKeeperScanPolicyObserver.ZKWatcher.html @@ -103,7 +103,7 @@

    -
    private static class ZooKeeperScanPolicyObserver.ZKWatcher
    +
    private static class ZooKeeperScanPolicyObserver.ZKWatcher
     extends Object
     implements org.apache.zookeeper.Watcher
    Internal watcher that keep "data" up to date asynchronously.
    @@ -226,7 +226,7 @@ implements org.apache.zookeeper.Watcher
    • data

      -
      private byte[] data
      +
      private byte[] data
    @@ -235,7 +235,7 @@ implements org.apache.zookeeper.Watcher
    @@ -244,7 +244,7 @@ implements org.apache.zookeeper.Watcher
  • @@ -253,7 +253,7 @@ implements org.apache.zookeeper.Watcher
  • @@ -270,7 +270,7 @@ implements org.apache.zookeeper.Watcher @@ -287,7 +287,7 @@ implements org.apache.zookeeper.Watcher
    • getData

      -
      public byte[] getData()
      +
      public byte[] getData()
      Get the maintained data. In case of any ZK exceptions this will retry establishing the connection (but not more than twice/minute). @@ -304,7 +304,7 @@ implements org.apache.zookeeper.Watcher
      • process

        -
        public void process(org.apache.zookeeper.WatchedEvent event)
        +
        public void process(org.apache.zookeeper.WatchedEvent event)
        Specified by:
        process in interface org.apache.zookeeper.Watcher
        http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a7e5a8ce/devapidocs/org/apache/hadoop/hbase/coprocessor/example/ZooKeeperScanPolicyObserver.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/coprocessor/example/ZooKeeperScanPolicyObserver.html b/devapidocs/org/apache/hadoop/hbase/coprocessor/example/ZooKeeperScanPolicyObserver.html index a65ad9e..6590e5e 100644 --- a/devapidocs/org/apache/hadoop/hbase/coprocessor/example/ZooKeeperScanPolicyObserver.html +++ b/devapidocs/org/apache/hadoop/hbase/coprocessor/example/ZooKeeperScanPolicyObserver.html @@ -104,7 +104,7 @@


        -
        public class ZooKeeperScanPolicyObserver
        +
        public class ZooKeeperScanPolicyObserver
         extends BaseRegionObserver
        This is an example showing how a RegionObserver could configured via ZooKeeper in order to control a Region compaction, flush, and scan policy. @@ -305,7 +305,7 @@ extends
      • node

        -
        public static final String node
        +
        public static final String node
        See Also:
        Constant Field Values
      @@ -315,7 +315,7 @@ extends
    • zkkey

      -
      public static final String zkkey
      +
      public static final String zkkey
      See Also:
      Constant Field Values
    @@ -325,7 +325,7 @@ extends
  • LOG

    -
    private static final org.apache.commons.logging.Log LOG
    +
    private static final org.apache.commons.logging.Log LOG
  • @@ -342,7 +342,7 @@ extends
  • ZooKeeperScanPolicyObserver

    -
    public ZooKeeperScanPolicyObserver()
    +
    public ZooKeeperScanPolicyObserver()
  • @@ -359,7 +359,7 @@ extends
  • start

    -
    public void start(CoprocessorEnvironment e)
    +
    public void start(CoprocessorEnvironment e)
                throws IOException
    Specified by:
    @@ -376,7 +376,7 @@ extends
  • stop

    -
    public void stop(CoprocessorEnvironment e)
    +
    public void stop(CoprocessorEnvironment e)
               throws IOException
    Specified by:
    @@ -393,7 +393,7 @@ extends
  • getScanInfo

    -
    protected ScanInfo getScanInfo(Store store,
    +
    protected ScanInfo getScanInfo(Store store,
                        RegionCoprocessorEnvironment e)
  • @@ -403,7 +403,7 @@ extends
  • preFlushScannerOpen

    -
    public InternalScanner preFlushScannerOpen(ObserverContext<RegionCoprocessorEnvironment> c,
    +
    public InternalScanner preFlushScannerOpen(ObserverContext<RegionCoprocessorEnvironment> c,
                                       Store store,
                                       KeyValueScanner memstoreScanner,
                                       InternalScanner s)
    @@ -433,7 +433,7 @@ extends 
     
  • preCompactScannerOpen

    -
    public InternalScanner preCompactScannerOpen(ObserverContext<RegionCoprocessorEnvironment> c,
    +
    public InternalScanner preCompactScannerOpen(ObserverContext<RegionCoprocessorEnvironment> c,
                                         Store store,
                                         List<? extends KeyValueScanner> scanners,
                                         ScanType scanType,
    @@ -467,7 +467,7 @@ extends 
     
  • preStoreScannerOpen

    -
    public KeyValueScanner preStoreScannerOpen(ObserverContext<RegionCoprocessorEnvironment> c,
    +
    public KeyValueScanner preStoreScannerOpen(ObserverContext<RegionCoprocessorEnvironment> c,
                                       Store store,
                                       Scan scan,
                                       NavigableSet<byte[]> targetCols,
    
    http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a7e5a8ce/devapidocs/org/apache/hadoop/hbase/executor/package-tree.html
    ----------------------------------------------------------------------
    diff --git a/devapidocs/org/apache/hadoop/hbase/executor/package-tree.html b/devapidocs/org/apache/hadoop/hbase/executor/package-tree.html
    index dc0d7a6..434ae88 100644
    --- a/devapidocs/org/apache/hadoop/hbase/executor/package-tree.html
    +++ b/devapidocs/org/apache/hadoop/hbase/executor/package-tree.html
    @@ -96,8 +96,8 @@