Interface and Description |
---|
org.apache.hadoop.hbase.client.AsyncTable.CheckAndMutateBuilder
Since 3.0.0, will be removed in 4.0.0. For internal test use only, do not use it
any more.
|
org.apache.hadoop.hbase.client.AsyncTable.CheckAndMutateWithFilterBuilder
Since 3.0.0, will be removed in 4.0.0. For internal test use only, do not use it
any more.
|
org.apache.hadoop.hbase.ipc.CoprocessorRpcChannel
Please stop using this class again, as it is too low level, which is part of the rpc
framework for HBase. Will be deleted in 4.0.0.
|
org.apache.hadoop.hbase.coprocessor.CoprocessorService
Since 2.0. Will be removed in 3.0
|
org.apache.hadoop.hbase.coprocessor.HasMasterServices
Since 2.0.0 to be removed in 3.0.0. The hope is that by 3.0.0 we will not need this
facility as CoreCoprocessors are integated into core.
|
org.apache.hadoop.hbase.coprocessor.HasRegionServerServices
Since 2.0.0 to be removed in 3.0.0. The hope is that by 3.0.0 we will not need this
facility as CoreCoprocessors are integated into core.
|
org.apache.hadoop.hbase.util.HbckErrorReporter
Since 2.3.0. To be removed in hbase4. Use HBCK2 instead. Remove when
HBaseFsck is removed. |
org.apache.hadoop.hbase.master.procedure.MetaProcedureInterface
only used for
RecoverMetaProcedure . Should be removed along with
RecoverMetaProcedure . |
org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination
since 2.4.0 and in 3.0.0, to be removed in 4.0.0, replaced by procedure-based
distributed WAL splitter, see SplitWALManager
|
org.apache.hadoop.hbase.coordination.SplitLogWorkerCoordination
since 2.4.0 and in 3.0.0, to be removed in 4.0.0, replaced by procedure-based
distributed WAL splitter, see SplitWALManager
|
org.apache.hadoop.hbase.client.Table.CheckAndMutateBuilder
Since 3.0.0, will be removed in 4.0.0. For internal test use only, do not use it
any more.
|
org.apache.hadoop.hbase.client.Table.CheckAndMutateWithFilterBuilder
Since 3.0.0, will be removed in 4.0.0. For internal test use only, do not use it
any more.
|
Class and Description |
---|
org.apache.hadoop.hbase.master.assignment.AssignProcedure
Do not use any more.
|
org.apache.hadoop.hbase.AuthUtil
since 2.2.0, to be marked as
InterfaceAudience.Private in 4.0.0. |
org.apache.hadoop.hbase.procedure2.store.wal.BitSetNode
Since 2.3.0, will be removed in 4.0.0. Keep here only for rolling upgrading, now we
use the new region based procedure store.
|
org.apache.hadoop.hbase.master.replication.ClaimReplicationQueuesProcedure
Use
AssignReplicationQueuesProcedure instead, kept only for keeping
compatibility. |
org.apache.hadoop.hbase.client.CoprocessorBlockingRpcCallback |
org.apache.hadoop.hbase.regionserver.DelimitedKeyPrefixRegionSplitPolicy
since 3.0.0 and will be removed in 4.0.0. Use
RegionSplitRestriction ,
instead. |
org.apache.hadoop.hbase.filter.FirstKeyValueMatchingQualifiersFilter
Deprecated in 2.0.0 and will be removed in 3.0.0.
|
org.apache.hadoop.hbase.master.assignment.GCMergedRegionsProcedure
2.3.0 Use
GCMultipleMergedRegionsProcedure . |
org.apache.hadoop.hbase.HBaseCluster
since 3.0.0, will be removed in 4.0.0. Use
TestingHBaseCluster instead. |
org.apache.hadoop.hbase.HBaseCommonTestingUtility
since 3.0.0, will be removed in 4.0.0. Use
TestingHBaseCluster instead. |
org.apache.hadoop.hbase.util.HBaseFsck
For removal in hbase-4.0.0. Use HBCK2 instead.
|
org.apache.hadoop.hbase.HBaseTestingUtility
since 3.0.0, will be removed in 4.0.0. Use
TestingHBaseCluster instead. |
org.apache.hadoop.hbase.HBaseZKTestingUtility
since 3.0.0, will be removed in 4.0.0. Use
TestingHBaseCluster instead. |
org.apache.hadoop.hbase.regionserver.HRegion.ReplayBatchOperation
Since 3.0.0, will be removed in 4.0.0. Now we will not use this operation to apply
edits at secondary replica side.
|
org.apache.hadoop.hbase.regionserver.KeyPrefixRegionSplitPolicy
since 3.0.0 and will be removed in 4.0.0. Use
RegionSplitRestriction ,
instead. |
org.apache.hadoop.hbase.KeyValue.KVComparator
: Use
CellComparatorImpl . Deprecated for hbase 2.0, remove for hbase 3.0. |
org.apache.hadoop.hbase.KeyValue.MetaComparator
:
MetaCellComparator.META_COMPARATOR to be used. Deprecated for hbase 2.0,
remove for hbase 3.0. |
org.apache.hadoop.hbase.client.LogQueryFilter
as of 2.4.0. Will be removed in 4.0.0.
|
org.apache.hadoop.hbase.client.MasterRegistry
Since 2.5.0, will be removed in 4.0.0. Use
RpcConnectionRegistry instead. |
org.apache.hadoop.hbase.master.procedure.MetaQueue
only used for
RecoverMetaProcedure . Should be removed along with
RecoverMetaProcedure . |
org.apache.hadoop.hbase.MiniHBaseCluster
since 3.0.0, will be removed in 4.0.0. Use
TestingHBaseCluster instead. |
org.apache.hadoop.hbase.master.assignment.MoveRegionProcedure
Do not use any more.
|
org.apache.hadoop.hbase.regionserver.handler.OpenRegionHandler
Keep it here only for compatible
|
org.apache.hadoop.hbase.procedure2.store.wal.ProcedureStoreTracker
Since 2.3.0, will be removed in 4.0.0. Keep here only for rolling upgrading, now we
use the new region based procedure store.
|
org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFile
Since 2.3.0, will be removed in 4.0.0. Keep here only for rolling upgrading, now we
use the new region based procedure store.
|
org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFormat
Since 2.3.0, will be removed in 4.0.0. Keep here only for rolling upgrading, now we
use the new region based procedure store.
|
org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFormatReader
Since 2.3.0, will be removed in 4.0.0. Keep here only for rolling upgrading, now we
use the new region based procedure store.
|
org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALPrettyPrinter
Since 2.3.0, will be removed in 4.0.0. Keep here only for rolling upgrading, now we
use the new region based procedure store.
|
org.apache.hadoop.hbase.master.procedure.RecoverMetaProcedure
Do not use any more, leave it here only for compatible. The recovery work will be
done in
ServerCrashProcedure directly, and the initial work for meta table
will be done by InitMetaProcedure . |
org.apache.hadoop.hbase.master.assignment.RegionTransitionProcedure
Do not use any more.
|
org.apache.hadoop.hbase.rsgroup.RSGroupAdminClient
Keep it here only for tests, using
Admin instead. |
org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
Keep it here only for compatibility with old client, all the logics have been moved
into core of HBase.
|
org.apache.hadoop.hbase.rsgroup.RSGroupAdminServiceImpl
Keep it here only for compatibility with
RSGroupAdminClient , using
MasterRpcServices instead. |
org.apache.hadoop.hbase.ipc.SimpleRpcServer |
org.apache.hadoop.hbase.ipc.SimpleRpcServerResponder |
org.apache.hadoop.hbase.ipc.SimpleServerCall |
org.apache.hadoop.hbase.ipc.SimpleServerRpcConnection |
org.apache.hadoop.hbase.SplitLogCounters
since 2.4.0 and in 3.0.0, to be removed in 4.0.0, replaced by procedure-based
distributed WAL splitter, see SplitWALManager
|
org.apache.hadoop.hbase.master.SplitLogManager
since 2.4.0 and in 3.0.0, to be removed in 4.0.0, replaced by procedure-based
distributed WAL splitter, see SplitWALManager.
|
org.apache.hadoop.hbase.SplitLogTask
since 2.4.0 and in 3.0.0, to be removed in 4.0.0, replaced by procedure-based
distributed WAL splitter, see SplitWALManager
|
org.apache.hadoop.hbase.regionserver.SplitLogWorker
since 2.4.0 and in 3.0.0, to be removed in 4.0.0, replaced by procedure-based
distributed WAL splitter, see SplitWALRemoteProcedure
|
org.apache.hadoop.hbase.StartMiniClusterOption
since 3.0.0, will be removed in 4.0.0. Use
TestingHBaseCluster instead. |
org.apache.hadoop.hbase.client.SyncCoprocessorRpcChannel
Please stop using this class again, as it is too low level, which is part of the rpc
framework for HBase. Will be deleted in 4.0.0.
|
org.apache.hadoop.hbase.master.cleaner.TimeToLiveProcedureWALCleaner
Since 2.3.0, will be removed in 4.0.0. We will not use the procedure wal to store
procedure any more.
|
org.apache.hadoop.hbase.master.assignment.UnassignProcedure
Do not use any more.
|
org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureMap
Since 2.3.0, will be removed in 4.0.0. Keep here only for rolling upgrading, now we
use the new region based procedure store.
|
org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
Since 2.3.0, will be removed in 4.0.0. Keep here only for rolling upgrading, now we
use the new region based procedure store.
|
org.apache.hadoop.hbase.regionserver.handler.WALSplitterHandler
since 2.4.0 and in 3.0.0, to be removed in 4.0.0, replaced by procedure-based
distributed WAL splitter, see SplitWALManager
|
org.apache.hadoop.hbase.coordination.ZkCoordinatedStateManager
since 2.4.0 and in 3.0.0, to be removed in 4.0.0, replaced by procedure-based
distributed WAL splitter (see SplitWALManager) which doesn't use this zk-based
coordinator.
|
org.apache.hadoop.hbase.util.ZKDataMigrator
Since 2.0.0. To be removed in hbase-3.0.0.
|
org.apache.hadoop.hbase.zookeeper.ZKLeaderManager
Not used
|
org.apache.hadoop.hbase.zookeeper.ZKSplitLog
since 2.4.0 and 3.0.0 replaced by procedure-based WAL splitting; see SplitWALManager.
|
org.apache.hadoop.hbase.zookeeper.ZKUtil.NodeAndData
Unused
|
Exceptions and Description |
---|
org.apache.hadoop.hbase.procedure2.store.wal.CorruptedWALProcedureStoreException
Since 2.3.0, will be removed in 4.0.0. Keep here only for rolling upgrading, now we
use the new region based procedure store.
|
org.apache.hadoop.hbase.exceptions.PreemptiveFastFailException
since 2.3.0, and will be removed in 4.0.0.
|
org.apache.hadoop.hbase.regionserver.RowTooBigException
since 0.99.0. Use
RowTooBigException instead. |
Field and Description |
---|
org.apache.hadoop.hbase.types.OrderedInt32.ASCENDING
since 3.0.0 and will be removed in 4.0.0
|
org.apache.hadoop.hbase.types.OrderedNumeric.ASCENDING
since 3.0.0 and will be removed in 4.0.0
|
org.apache.hadoop.hbase.types.OrderedInt8.ASCENDING
since 3.0.0 and will be removed in 4.0.0
|
org.apache.hadoop.hbase.types.OrderedFloat64.ASCENDING
since 3.0.0 and will be removed in 4.0.0
|
org.apache.hadoop.hbase.types.OrderedBlob.ASCENDING
since 3.0.0 and will be removed in 4.0.0
|
org.apache.hadoop.hbase.types.OrderedFloat32.ASCENDING
since 3.0.0 and will be removed in 4.0.0
|
org.apache.hadoop.hbase.types.OrderedString.ASCENDING
since 3.0.0 and will be removed in 4.0.0
|
org.apache.hadoop.hbase.types.OrderedInt16.ASCENDING
since 3.0.0 and will be removed in 4.0.0
|
org.apache.hadoop.hbase.types.RawBytes.ASCENDING
since 3.0.0 and will be removed in 4.0.0
|
org.apache.hadoop.hbase.types.OrderedBlobVar.ASCENDING
since 3.0.0 and will be removed in 4.0.0
|
org.apache.hadoop.hbase.types.RawString.ASCENDING
since 3.0.0 and will be removed in 4.0.0
|
org.apache.hadoop.hbase.types.OrderedInt64.ASCENDING
since 3.0.0 and will be removed in 4.0.0
|
org.apache.hadoop.hbase.zookeeper.ZNodePaths.balancerZNode
Since 2.6.0, will be removed in 4.0.0. We use master local region to store this
state.
|
org.apache.hadoop.hbase.http.HttpServer.Builder.bindAddress
Since 0.99.0. Use builder pattern via
HttpServer.Builder.addEndpoint(URI) instead. |
org.apache.hadoop.hbase.client.BufferedMutator.CLASSNAME_KEY
Since 3.0.0, will be removed in 4.0.0. For internal test use only, do not use it
any more.
|
org.apache.hadoop.hbase.wal.WALEdit.COMPACTION
Since 2.3.0. Make it protected, internal-use only. Use
WALEdit.isCompactionMarker(Cell) |
org.apache.hadoop.hbase.KeyValue.COMPARATOR
Use
CellComparator.getInstance() instead. Deprecated for hbase 2.0, remove
for hbase 3.0. |
org.apache.hadoop.hbase.HConstants.DEFAULT_HBASE_SPLIT_COORDINATED_BY_ZK
since 2.4.0 and in 3.0.0, to be removed in 4.0.0.
|
org.apache.hadoop.hbase.HConstants.DEFAULT_META_REPLICA_NUM
Since 2.4.0, will be removed in 4.0.0. Please change the meta replicas number by
altering meta table, i.e, set a new 'region replication' number and call
modifyTable.
|
org.apache.hadoop.hbase.io.ByteBuffAllocator.DEPRECATED_ALLOCATOR_POOL_ENABLED_KEY
since 2.3.0 and will be removed in 4.0.0. Use
ByteBuffAllocator.ALLOCATOR_POOL_ENABLED_KEY instead. |
org.apache.hadoop.hbase.io.hfile.BlockCacheFactory.DEPRECATED_BLOCKCACHE_BLOCKSIZE_KEY
use
BlockCacheFactory.BLOCKCACHE_BLOCKSIZE_KEY instead. |
org.apache.hadoop.hbase.io.ByteBuffAllocator.DEPRECATED_BUFFER_SIZE_KEY
since 2.3.0 and will be removed in 4.0.0. Use
ByteBuffAllocator.BUFFER_SIZE_KEY instead. |
org.apache.hadoop.hbase.io.ByteBuffAllocator.DEPRECATED_MAX_BUFFER_COUNT_KEY
since 2.3.0 and will be removed in 4.0.0. Use
ByteBuffAllocator.MAX_BUFFER_COUNT_KEY instead. |
org.apache.hadoop.hbase.types.OrderedInt32.DESCENDING
since 3.0.0 and will be removed in 4.0.0
|
org.apache.hadoop.hbase.types.OrderedNumeric.DESCENDING
since 3.0.0 and will be removed in 4.0.0
|
org.apache.hadoop.hbase.types.OrderedInt8.DESCENDING
since 3.0.0 and will be removed in 4.0.0
|
org.apache.hadoop.hbase.types.OrderedFloat64.DESCENDING
since 3.0.0 and will be removed in 4.0.0
|
org.apache.hadoop.hbase.types.OrderedBlob.DESCENDING
since 3.0.0 and will b removed in 4.0.0
|
org.apache.hadoop.hbase.types.OrderedFloat32.DESCENDING
since 3.0.0 and will be removed in 4.0.0
|
org.apache.hadoop.hbase.types.OrderedString.DESCENDING
since 3.0.0 and will be removed in 4.0.0
|
org.apache.hadoop.hbase.types.OrderedInt16.DESCENDING
since 3.0.0 and will be removed in 4.0.0
|
org.apache.hadoop.hbase.types.RawBytes.DESCENDING
since 3.0.0 and will be removed in 4.0.0
|
org.apache.hadoop.hbase.types.OrderedBlobVar.DESCENDING
since 3.0.0 and will be removed in 4.0.0
|
org.apache.hadoop.hbase.types.RawString.DESCENDING
since 3.0.0 and will be removed in 4.0.0
|
org.apache.hadoop.hbase.types.OrderedInt64.DESCENDING
since 3.0.0 and will be removed in 4.0.0
|
org.apache.hadoop.hbase.mapreduce.SimpleTotalOrderPartitioner.END
since 0.90.0
|
org.apache.hadoop.hbase.wal.WALEdit.FLUSH
Since 2.3.0. Make it protected, internal-use only.
|
org.apache.hadoop.hbase.HConstants.HBASE_CLIENT_ENABLE_FAST_FAIL_MODE_DEFAULT
since 2.3.0, and in 3.0.0 the actually implementation will be removed so config
this value will have no effect. The constants itself will be removed in 4.0.0.
|
org.apache.hadoop.hbase.HConstants.HBASE_CLIENT_FAILURE_MAP_CLEANUP_INTERVAL_MS
since 2.3.0, and in 3.0.0 the actually implementation will be removed so config
this value will have no effect. The constants itself will be removed in 4.0.0.
|
org.apache.hadoop.hbase.HConstants.HBASE_CLIENT_FAILURE_MAP_CLEANUP_INTERVAL_MS_DEFAULT
since 2.3.0, and in 3.0.0 the actually implementation will be removed so config
this value will have no effect. The constants itself will be removed in 4.0.0.
|
org.apache.hadoop.hbase.HConstants.HBASE_CLIENT_FAST_FAIL_CLEANUP_DURATION_MS_DEFAULT
since 2.3.0, and in 3.0.0 the actually implementation will be removed so config
this value will have no effect. The constants itself will be removed in 4.0.0.
|
org.apache.hadoop.hbase.HConstants.HBASE_CLIENT_FAST_FAIL_CLEANUP_MS_DURATION_MS
since 2.3.0, and in 3.0.0 the actually implementation will be removed so config
this value will have no effect. The constants itself will be removed in 4.0.0.
|
org.apache.hadoop.hbase.HConstants.HBASE_CLIENT_FAST_FAIL_INTERCEPTOR_IMPL
since 2.3.0, and in 3.0.0 the actually implementation will be removed so config
this value will have no effect. The constants itself will be removed in 4.0.0.
|
org.apache.hadoop.hbase.HConstants.HBASE_CLIENT_FAST_FAIL_MODE_ENABLED
since 2.3.0, and in 3.0.0 the actually implementation will be removed so config
this value will have no effect. The constants itself will be removed in 4.0.0.
|
org.apache.hadoop.hbase.HConstants.HBASE_CLIENT_FAST_FAIL_THREASHOLD_MS
since 2.3.0, and in 3.0.0 the actually implementation will be removed so config
this value will have no effect. The constants itself will be removed in 4.0.0.
|
org.apache.hadoop.hbase.HConstants.HBASE_CLIENT_FAST_FAIL_THREASHOLD_MS_DEFAULT
since 2.3.0, and in 3.0.0 the actually implementation will be removed so config
this value will have no effect. The constants itself will be removed in 4.0.0.
|
org.apache.hadoop.hbase.HConstants.HBASE_CLIENT_PAUSE_FOR_CQTBE
Since 2.5.0, will be removed in 4.0.0. Please use
hbase.client.pause.server.overloaded instead.
|
org.apache.hadoop.hbase.HConstants.HBASE_NON_USER_TABLE_DIRS
Since hbase-2.3.0; no replacement as not used any more (internally at least)
|
org.apache.hadoop.hbase.master.LoadBalancer.HBASE_RSGROUP_LOADBALANCER_CLASS
since 3.0.0, will be removed in 4.0.0. In the new implementation, as the base load
balancer will always be the rs group based one, you should just use
HConstants.HBASE_MASTER_LOADBALANCER_CLASS to
config the per group load balancer. |
org.apache.hadoop.hbase.HConstants.HBASE_SPLIT_WAL_COORDINATED_BY_ZK
since 2.4.0 and in 3.0.0, to be removed in 4.0.0, replaced by procedure-based
distributed WAL splitter; see SplitWALManager.
|
org.apache.hadoop.hbase.mapreduce.TableSplit.LOG
LOG variable would be made private. fix in hbase 3.0
|
org.apache.hadoop.hbase.HConstants.MERGEA_QUALIFIER
Since 2.3.0 and 2.2.1. Not used anymore. Instead we look for the
HConstants.MERGE_QUALIFIER_PREFIX_STR prefix. |
org.apache.hadoop.hbase.HConstants.MERGEB_QUALIFIER
Since 2.3.0 and 2.2.1. Not used anymore. Instead we look for the
HConstants.MERGE_QUALIFIER_PREFIX_STR prefix. |
org.apache.hadoop.hbase.KeyValue.META_COMPARATOR
Use
MetaCellComparator.META_COMPARATOR instead. Deprecated for hbase 2.0,
remove for hbase 3.0. |
org.apache.hadoop.hbase.HConstants.META_REPLICAS_NUM
Since 2.4.0, will be removed in 4.0.0. Please change the meta replicas number by
altering meta table, i.e, set a new 'region replication' number and call
modifyTable.
|
org.apache.hadoop.hbase.wal.WALEdit.METAROW
Since 2.3.0. Not used.
|
org.apache.hadoop.hbase.metrics.BaseSourceImpl.metricsRegistry
Use hbase-metrics/hbase-metrics-api module interfaces for new metrics. Defining
BaseSources for new metric groups (WAL, RPC, etc) is not needed anymore, however,
for existing
BaseSource implementations, please use the field named
"registry" which is a MetricRegistry instance together with the
HBaseMetrics2HadoopMetricsAdapter . |
org.apache.hadoop.hbase.master.normalizer.SimpleRegionNormalizer.MIN_REGION_COUNT_KEY
since 2.5.0 and will be removed in 4.0.0. Use
SimpleRegionNormalizer.MERGE_MIN_REGION_COUNT_KEY instead. |
org.apache.hadoop.hbase.http.HttpServer.Builder.name
Since 0.99.0. Use builder pattern via
HttpServer.Builder.setAppDir(String) instead. |
org.apache.hadoop.hbase.client.TableDescriptorBuilder.NAMESPACE_COL_DESC_BYTES
namespace table has been folded into the ns family in meta table, do not use this
any more.
|
org.apache.hadoop.hbase.client.TableDescriptorBuilder.NAMESPACE_FAMILY_INFO
namespace table has been folded into the ns family in meta table, do not use this
any more.
|
org.apache.hadoop.hbase.client.TableDescriptorBuilder.NAMESPACE_FAMILY_INFO_BYTES
namespace table has been folded into the ns family in meta table, do not use this
any more.
|
org.apache.hadoop.hbase.TableName.NAMESPACE_TABLE_NAME
since 3.0.0 and will be removed in 4.0.0. We have folded the data in namespace
table into meta table, so do not use it any more.
|
org.apache.hadoop.hbase.client.TableDescriptorBuilder.NAMESPACE_TABLEDESC
since 3.0.0 and will be removed in 4.0.0. We have folded the data in namespace
table into meta table, so do not use it any more.
|
org.apache.hadoop.hbase.client.TableDescriptorBuilder.NORMALIZER_TARGET_REGION_SIZE |
org.apache.hadoop.hbase.client.TableDescriptorBuilder.NORMALIZER_TARGET_REGION_SIZE_KEY |
org.apache.hadoop.hbase.master.procedure.MasterProcedureUtil.PATTERN
Since 2.3.0, will be removed in 4.0.0. We do not use this style of procedure wal
file name any more.
|
org.apache.hadoop.hbase.http.HttpServer.Builder.port
Since 0.99.0. Use builder pattern via
HttpServer.Builder.addEndpoint(URI) instead. |
org.apache.hadoop.hbase.regionserver.KeyPrefixRegionSplitPolicy.PREFIX_LENGTH_KEY_DEPRECATED |
org.apache.hadoop.hbase.wal.WALEdit.REGION_EVENT
Since 2.3.0. Remove. Not for external use. Not used.
|
org.apache.hadoop.hbase.util.ServerRegionReplicaUtil.REGION_REPLICA_REPLICATION_PEER
Since 3.0.0, leave here only for implementing compatibility code.
|
org.apache.hadoop.hbase.zookeeper.ZNodePaths.regionNormalizerZNode
Since 2.6.0, will be removed in 4.0.0. We use master local region to store this
state.
|
org.apache.hadoop.hbase.HConstants.REPLAY_QOS
since 3.0.0, will be removed in 4.0.0. DLR has been purged for a long time and
region replication has its own 'replay' method.
|
org.apache.hadoop.hbase.HConstants.REPLICATION_DROP_ON_DELETED_TABLE_KEY
since 3.0.0. Will be removed in 4.0.0. Moved it into
HBaseInterClusterReplicationEndpoint.
|
org.apache.hadoop.hbase.regionserver.HRegionServer.RS_HOSTNAME_DISABLE_MASTER_REVERSEDNS_KEY
since 2.4.0 and will be removed in 4.0.0. Use
HRegionServer.UNSAFE_RS_HOSTNAME_DISABLE_MASTER_REVERSEDNS_KEY instead. |
org.apache.hadoop.hbase.util.DNS.RS_HOSTNAME_KEY
since 2.4.0 and will be removed in 4.0.0. Use
DNS.UNSAFE_RS_HOSTNAME_KEY
instead. |
org.apache.hadoop.hbase.regionserver.RSRpcServices.SCANNER_ALREADY_CLOSED |
org.apache.hadoop.hbase.HConstants.SLOW_LOG_SYS_TABLE_CHORE_DURATION_KEY |
org.apache.hadoop.hbase.zookeeper.ZNodePaths.snapshotCleanupZNode
Since 2.6.0, will be removed in 4.0.0. We use master local region to store this
state.
|
org.apache.hadoop.hbase.master.MasterWalManager.splitLogManager
since 2.3.0 and 3.0.0 to be removed in 4.0.0; replaced by
SplitWALManager . |
org.apache.hadoop.hbase.mapreduce.SimpleTotalOrderPartitioner.START
since 0.90.0
|
org.apache.hadoop.hbase.zookeeper.ZNodePaths.switchZNode
Since 2.6.0, will be removed in 4.0.0. We use master local region to store this
state.
|
org.apache.hadoop.hbase.rsgroup.RSGroupInfo.tables
Since 3.0.0, will be removed in 4.0.0. The rsgroup information will be stored in
the configuration of a table so this will be removed.
|
org.apache.hadoop.hbase.zookeeper.ZNodePaths.tableZNode |
org.apache.hadoop.hbase.HBaseTestingUtility.TEST_DIRECTORY_KEY
since 2.0.0 and will be removed in 3.0.0. Can be used only with mini dfs.
|
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.