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 073D418E5A for ; Thu, 17 Dec 2015 17:20:10 +0000 (UTC) Received: (qmail 14860 invoked by uid 500); 17 Dec 2015 17:20:06 -0000 Delivered-To: apmail-hbase-commits-archive@hbase.apache.org Received: (qmail 14763 invoked by uid 500); 17 Dec 2015 17:20:06 -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 13927 invoked by uid 99); 17 Dec 2015 17:20:05 -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; Thu, 17 Dec 2015 17:20:05 +0000 Received: by git1-us-west.apache.org (ASF Mail Server at git1-us-west.apache.org, from userid 33) id B8946E6969; Thu, 17 Dec 2015 17:20:05 +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: Thu, 17 Dec 2015 17:20:37 -0000 Message-Id: <5fc7c5fe465e446986b3b82663f973c7@git.apache.org> In-Reply-To: <5d67ec6f08544de986d4af78f447a0eb@git.apache.org> References: <5d67ec6f08544de986d4af78f447a0eb@git.apache.org> X-Mailer: ASF-Git Admin Mailer Subject: [36/51] [partial] hbase-site git commit: Published site at cf458d302385f8e32dd444f4820cfd72a8694862. http://git-wip-us.apache.org/repos/asf/hbase-site/blob/aa343563/devapidocs/deprecated-list.html ---------------------------------------------------------------------- diff --git a/devapidocs/deprecated-list.html b/devapidocs/deprecated-list.html index 76df3dc..2a92799 100644 --- a/devapidocs/deprecated-list.html +++ b/devapidocs/deprecated-list.html @@ -2,7 +2,7 @@ - + Deprecated List (Apache HBase 2.0.0-SNAPSHOT API) @@ -299,6 +299,12 @@ +org.apache.hadoop.hbase.client.HBaseAdmin.addColumn(TableName, HColumnDescriptor) +
Since 2.0. Will be removed in 3.0. Use + HBaseAdmin.addColumnFamily(TableName, HColumnDescriptor) instead.
+ + + org.apache.hadoop.hbase.client.Admin.addColumn(TableName, HColumnDescriptor)
As of release 2.0.0. (HBASE-1989). @@ -306,12 +312,6 @@ Use Admin.addColumnFamily(TableName, HColumnDescriptor).
- -org.apache.hadoop.hbase.client.HBaseAdmin.addColumn(TableName, HColumnDescriptor) -
Since 2.0. Will be removed in 3.0. Use - HBaseAdmin.addColumnFamily(TableName, HColumnDescriptor) instead.
- - org.apache.hadoop.hbase.security.visibility.VisibilityClient.addLabel(Configuration, String) @@ -389,10 +389,10 @@ org.apache.hadoop.hbase.mapreduce.CellCreator.create(byte[], int, int, byte[], int, int, byte[], int, int, long, byte[], int, int, String) -org.apache.hadoop.hbase.regionserver.RpcSchedulerFactory.create(Configuration, PriorityFunction) +org.apache.hadoop.hbase.regionserver.SimpleRpcSchedulerFactory.create(Configuration, PriorityFunction) -org.apache.hadoop.hbase.regionserver.SimpleRpcSchedulerFactory.create(Configuration, PriorityFunction) +org.apache.hadoop.hbase.regionserver.RpcSchedulerFactory.create(Configuration, PriorityFunction) org.apache.hadoop.hbase.client.HConnection.deleteCachedRegionLocation(HRegionLocation) @@ -400,6 +400,12 @@ +org.apache.hadoop.hbase.client.HBaseAdmin.deleteColumn(TableName, byte[]) +
Since 2.0. Will be removed in 3.0. Use + HBaseAdmin.deleteColumnFamily(TableName, byte[]) instead.
+ + + org.apache.hadoop.hbase.client.Admin.deleteColumn(TableName, byte[])
As of release 2.0.0. (HBASE-1989). @@ -407,12 +413,6 @@ Use Admin.deleteColumnFamily(TableName, byte[])}.
- -org.apache.hadoop.hbase.client.HBaseAdmin.deleteColumn(TableName, byte[]) -
Since 2.0. Will be removed in 3.0. Use - HBaseAdmin.deleteColumnFamily(TableName, byte[]) instead.
- - org.apache.hadoop.hbase.KeyValueUtil.ensureKeyValue(Cell)
without any replacement.
@@ -422,13 +422,13 @@ org.apache.hadoop.hbase.KeyValueUtil.ensureKeyValues(List) -org.apache.hadoop.hbase.regionserver.RegionMergeTransaction.execute(Server, RegionServerServices) -
use #execute(Server, RegionServerServices, User)
+org.apache.hadoop.hbase.regionserver.SplitTransaction.execute(Server, RegionServerServices) +
use #execute(Server, RegionServerServices, User); as of 1.0.2, remove in 3.0
-org.apache.hadoop.hbase.regionserver.SplitTransaction.execute(Server, RegionServerServices) -
use #execute(Server, RegionServerServices, User); as of 1.0.2, remove in 3.0
+org.apache.hadoop.hbase.regionserver.RegionMergeTransaction.execute(Server, RegionServerServices) +
use #execute(Server, RegionServerServices, User)
@@ -575,12 +575,12 @@ -org.apache.hadoop.hbase.client.ClusterConnection.getKeepAliveMasterService() +org.apache.hadoop.hbase.client.HConnection.getKeepAliveMasterService()
Since 0.96.0
-org.apache.hadoop.hbase.client.HConnection.getKeepAliveMasterService() +org.apache.hadoop.hbase.client.ClusterConnection.getKeepAliveMasterService()
Since 0.96.0
@@ -609,10 +609,10 @@ org.apache.hadoop.hbase.HTableDescriptor.getOwnerString() -org.apache.hadoop.hbase.http.HttpServer.getPort() +org.apache.hadoop.hbase.http.InfoServer.getPort() -org.apache.hadoop.hbase.http.InfoServer.getPort() +org.apache.hadoop.hbase.http.HttpServer.getPort() org.apache.hadoop.hbase.CellUtil.getQualifierBufferShallowCopy(Cell) @@ -725,13 +725,13 @@ org.apache.hadoop.hbase.KeyValue.getType() -org.apache.hadoop.hbase.client.HTableInterface.getWriteBufferSize() -
as of 1.0.0. Replaced by BufferedMutator.getWriteBufferSize()
+org.apache.hadoop.hbase.client.Table.getWriteBufferSize() +
as of 1.0.1 (should not have been in 1.0.0). Replaced by BufferedMutator.getWriteBufferSize()
-org.apache.hadoop.hbase.client.Table.getWriteBufferSize() -
as of 1.0.1 (should not have been in 1.0.0). Replaced by BufferedMutator.getWriteBufferSize()
+org.apache.hadoop.hbase.client.HTableInterface.getWriteBufferSize() +
as of 1.0.0. Replaced by BufferedMutator.getWriteBufferSize()
@@ -758,12 +758,12 @@ org.apache.hadoop.hbase.KeyValue.iscreate(InputStream) -org.apache.hadoop.hbase.client.ClusterConnection.isDeadServer(ServerName) +org.apache.hadoop.hbase.client.HConnection.isDeadServer(ServerName)
internal method, do not use thru HConnection
-org.apache.hadoop.hbase.client.HConnection.isDeadServer(ServerName) +org.apache.hadoop.hbase.client.ClusterConnection.isDeadServer(ServerName)
internal method, do not use thru HConnection
@@ -774,18 +774,18 @@ org.apache.hadoop.hbase.master.cleaner.BaseLogCleanerDelegate.isLogDeletable(FileStatus) -org.apache.hadoop.hbase.client.ClusterConnection.isMasterRunning() +org.apache.hadoop.hbase.client.ConnectionImplementation.isMasterRunning()
this has been deprecated without a replacement
-org.apache.hadoop.hbase.client.ConnectionImplementation.isMasterRunning() -
this has been deprecated without a replacement
+org.apache.hadoop.hbase.client.HConnection.isMasterRunning() +
internal method, do not use thru HConnection
-org.apache.hadoop.hbase.client.HConnection.isMasterRunning() -
internal method, do not use thru HConnection
+org.apache.hadoop.hbase.client.ClusterConnection.isMasterRunning() +
this has been deprecated without a replacement
@@ -885,6 +885,12 @@ +org.apache.hadoop.hbase.client.HBaseAdmin.modifyColumn(TableName, HColumnDescriptor) +
As of 2.0. Will be removed in 3.0. Use + HBaseAdmin.modifyColumnFamily(TableName, HColumnDescriptor) instead.
+ + + org.apache.hadoop.hbase.client.Admin.modifyColumn(TableName, HColumnDescriptor)
As of release 2.0.0. (HBASE-1989). @@ -892,12 +898,6 @@ Use Admin.modifyColumnFamily(TableName, HColumnDescriptor).
- -org.apache.hadoop.hbase.client.HBaseAdmin.modifyColumn(TableName, HColumnDescriptor) -
As of 2.0. Will be removed in 3.0. Use - HBaseAdmin.modifyColumnFamily(TableName, HColumnDescriptor) instead.
- - org.apache.hadoop.hbase.KeyValue.oswrite(KeyValue, OutputStream, boolean)
As of release 2.0.0, this will be removed in HBase 3.0.0. @@ -1010,14 +1010,14 @@ -org.apache.hadoop.hbase.coprocessor.BaseRegionObserver.postScannerFilterRow(ObserverContext, InternalScanner, byte[], int, short, boolean) - - org.apache.hadoop.hbase.coprocessor.RegionObserver.postScannerFilterRow(ObserverContext, InternalScanner, byte[], int, short, boolean)
As of release 2.0.0, this will be removed in HBase 3.0.0. Instead use RegionObserver.postScannerFilterRow(ObserverContext, InternalScanner, Cell, boolean)
+ +org.apache.hadoop.hbase.coprocessor.BaseRegionObserver.postScannerFilterRow(ObserverContext, InternalScanner, byte[], int, short, boolean) + org.apache.hadoop.hbase.coprocessor.RegionObserver.postSplit(ObserverContext, Region, Region)
Use postCompleteSplit() instead
@@ -1282,13 +1282,13 @@ -org.apache.hadoop.hbase.regionserver.RegionMergeTransaction.rollback(Server, RegionServerServices) -
use #rollback(Server, RegionServerServices, User)
+org.apache.hadoop.hbase.regionserver.SplitTransaction.rollback(Server, RegionServerServices) +
use #rollback(Server, RegionServerServices, User); as of 1.0.2, remove in 3.0
-org.apache.hadoop.hbase.regionserver.SplitTransaction.rollback(Server, RegionServerServices) -
use #rollback(Server, RegionServerServices, User); as of 1.0.2, remove in 3.0
+org.apache.hadoop.hbase.regionserver.RegionMergeTransaction.rollback(Server, RegionServerServices) +
use #rollback(Server, RegionServerServices, User)
@@ -1364,19 +1364,19 @@ -org.apache.hadoop.hbase.client.BufferedMutatorImpl.setWriteBufferSize(long) -
Going away when we drop public support for HTableInterface.
+org.apache.hadoop.hbase.client.Table.setWriteBufferSize(long) +
as of 1.0.1 (should not have been in 1.0.0). Replaced by BufferedMutator and + BufferedMutatorParams.writeBufferSize(long)
-org.apache.hadoop.hbase.client.HTableInterface.setWriteBufferSize(long) - +org.apache.hadoop.hbase.client.BufferedMutatorImpl.setWriteBufferSize(long) +
Going away when we drop public support for HTableInterface.
-org.apache.hadoop.hbase.client.Table.setWriteBufferSize(long) -
as of 1.0.1 (should not have been in 1.0.0). Replaced by BufferedMutator and +org.apache.hadoop.hbase.client.HTableInterface.setWriteBufferSize(long) + http://git-wip-us.apache.org/repos/asf/hbase-site/blob/aa343563/devapidocs/help-doc.html ---------------------------------------------------------------------- diff --git a/devapidocs/help-doc.html b/devapidocs/help-doc.html index 57abe7c..6bfa499 100644 --- a/devapidocs/help-doc.html +++ b/devapidocs/help-doc.html @@ -2,7 +2,7 @@ - + API Help (Apache HBase 2.0.0-SNAPSHOT API) http://git-wip-us.apache.org/repos/asf/hbase-site/blob/aa343563/devapidocs/index-all.html ---------------------------------------------------------------------- diff --git a/devapidocs/index-all.html b/devapidocs/index-all.html index be46e97..66be2ab 100644 --- a/devapidocs/index-all.html +++ b/devapidocs/index-all.html @@ -2,7 +2,7 @@ - + Index (Apache HBase 2.0.0-SNAPSHOT API) @@ -6099,6 +6099,8 @@
 
calculateIsMetaRegion() - Method in class org.apache.hadoop.hbase.HTableDescriptor
 
+
calculateMaxLogFiles(float, long) - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
+
 
calculateMutationSize(Mutation) - Static method in class org.apache.hadoop.hbase.quotas.QuotaUtil
 
calculateNumMetaBytes() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
@@ -7432,8 +7434,6 @@ Throw exception if the table exists on peer cluster but descriptors are not same.
-
checkAndTryRoll() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
 
checkAndUpdateNamespaceQuota(SnapshotManifest, TableName) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
 
checkAndUpdateNamespaceRegionCount(TableName, byte[], int) - Method in class org.apache.hadoop.hbase.namespace.NamespaceStateManager
@@ -42561,8 +42561,6 @@
 
IN_MEMORY - Static variable in class org.apache.hadoop.hbase.rest.model.ColumnSchemaModel
 
-
inactiveLogsMaxId - Variable in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
 
inArchive - Variable in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats.FileInfo
 
inArchive() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats.FileInfo
@@ -44164,10 +44162,10 @@
When a procedure is submitted to the executor insert(proc, null) will be called.
-
insert(Procedure, Procedure[]) - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreTracker
-
 
insert(long) - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreTracker
 
+
insert(long, long[]) - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreTracker
+
 
insert(Procedure, Procedure[]) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
 
insert(int, CopyOnWriteArrayMap.COWEntry<K, V>) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap.ArrayHolder
@@ -49714,6 +49712,8 @@
 
LOG - Static variable in class org.apache.hadoop.hbase.client.ClientScanner
 
+
LOG - Static variable in class org.apache.hadoop.hbase.client.ClientSideRegionScanner
+
 
LOG - Static variable in class org.apache.hadoop.hbase.client.ClientSmallReversedScanner
 
LOG - Static variable in class org.apache.hadoop.hbase.client.ClientSmallScanner
@@ -49730,6 +49730,8 @@
 
LOG - Static variable in class org.apache.hadoop.hbase.client.example.MultiThreadedClientExample
 
+
LOG - Static variable in class org.apache.hadoop.hbase.client.FlushRegionCallable
+
 
LOG - Static variable in class org.apache.hadoop.hbase.client.Get
 
LOG - Static variable in class org.apache.hadoop.hbase.client.HBaseAdmin
@@ -53174,6 +53176,10 @@
 
MEMCACHED_OPTIMEOUT_KEY - Static variable in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
 
+
MEMCACHED_OPTIMIZE_DEFAULT - Static variable in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
+
 
+
MEMCACHED_OPTIMIZE_KEY - Static variable in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
+
 
MEMCACHED_TIMEOUT_KEY - Static variable in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
 
MemcachedBlockCache - Class in org.apache.hadoop.hbase.io.hfile
@@ -59863,6 +59869,8 @@ service.
 
periodicRoll() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
 
+
periodicRollForTesting() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
+
 
periodicRollMsec - Variable in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
 
PERM_ALL_ACCESS - Static variable in class org.apache.hadoop.hbase.replication.regionserver.HFileReplicator
@@ -64408,7 +64416,7 @@ service.
 
purpose - Variable in class org.apache.hadoop.hbase.master.TableLockManager.ZKTableLockManager.TableLockImpl
 
-
pushData(ByteSlot) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
+
pushData(WALProcedureStore.PushType, ByteSlot, long, long[]) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
 
put(Put) - Method in class org.apache.hadoop.hbase.client.HTable
@@ -71821,6 +71829,8 @@ service.
Roll the log writer.
+
rollWriterForTesting() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
+
 
rollWriterLock - Variable in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
This lock makes sure only one log roll runs at a time.
@@ -74308,6 +74318,8 @@ service.
Called on stop/abort before closing the cluster connection and meta locator.
+
sendStopSignal() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
+
 
SENT_BYTES_DESC - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
SENT_BYTES_NAME - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
@@ -76372,8 +76384,6 @@ service.
setIgnorePreCheckPermission(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
 
-
setInactiveLogsMaxId(long) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
 
setIncludesMemstoreTS(boolean) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileBlock.FSReader
 
setIncludesMemstoreTS(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock.FSReaderImpl
@@ -87232,6 +87242,8 @@ service.
Try to retire the current chunk if it is still c.
+
tryRollWriter() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
+
 
trySetResultSimple(int, Row, boolean, Object, ServerName, boolean) - Method in class org.apache.hadoop.hbase.client.AsyncProcess.AsyncRequestFutureImpl
Tries to set the result or error for a particular action as if there were no replica calls.
@@ -87903,8 +87915,6 @@ service.
update(long) - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreTracker.BitSetNode
 
-
update(Procedure) - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreTracker
-
 
update(long) - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreTracker
 
update(Procedure) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
@@ -88585,6 +88595,8 @@ service.
updateStorefiles(List<StoreFile>, long) - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
+
updateStoreTracker(WALProcedureStore.PushType, long, long[]) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
+
 
updateTableCache(TableName, ListMultimap<String, TablePermission>) - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
Updates the internal permissions cache for a single table, splitting @@ -89540,6 +89552,10 @@ service.
Returns the enum constant of this type with the specified name.
+
valueOf(String) - Static method in enum org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore.PushType
+
+
Returns the enum constant of this type with the specified name.
+
valueOf(String) - Static method in enum org.apache.hadoop.hbase.quotas.OperationQuota.OperationType
Returns the enum constant of this type with the specified name.
@@ -90121,6 +90137,11 @@ the order they are declared.
Returns an array containing the constants of this enum type, in the order they are declared.
+
values() - Static method in enum org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore.PushType
+
+
Returns an array containing the constants of this enum type, in +the order they are declared.
+
values() - Static method in enum org.apache.hadoop.hbase.quotas.OperationQuota.OperationType
Returns an array containing the constants of this enum type, in @@ -91492,6 +91513,10 @@ the order they are declared.
 
WALProcedureStore.LeaseRecovery - Interface in org.apache.hadoop.hbase.procedure2.store.wal
 
+
WALProcedureStore.PushType - Enum in org.apache.hadoop.hbase.procedure2.store.wal
+
 
+
WALProcedureStore.PushType() - Constructor for enum org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore.PushType
+
 
WALProvider - Interface in org.apache.hadoop.hbase.wal
The Write Ahead Log (WAL) stores all durable edits to the HRegion.
http://git-wip-us.apache.org/repos/asf/hbase-site/blob/aa343563/devapidocs/index.html ---------------------------------------------------------------------- diff --git a/devapidocs/index.html b/devapidocs/index.html index f02c439..b3afefa 100644 --- a/devapidocs/index.html +++ b/devapidocs/index.html @@ -2,7 +2,7 @@ - + Apache HBase 2.0.0-SNAPSHOT API