• Deprecated Interfaces
    Interface
    Description
    org.apache.hadoop.hbase.client.AsyncTable.CheckAndMutateBuilder
    Since 2.4.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 2.4.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.CheckAndMutateBuilder
    Since 2.4.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 2.4.0, will be removed in 4.0.0. For internal test use only, do not use it any more.
    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.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.coprocessor.SingletonCoprocessorService
    Since 2.0. Will be removed in 3.0
    org.apache.hadoop.hbase.regionserver.RowProcessor
    As of release 2.0.0, this will be removed in HBase 3.0.0. For customization, use Coprocessors instead.
    org.apache.hadoop.hbase.util.HbckErrorReporter
    Since 2.3.0. To be removed in hbase4. Use HBCK2 instead. Remove when HBaseFsck is removed.
  • Deprecated Classes
    Class
    Description
    org.apache.hadoop.hbase.AuthUtil
    since 2.2.0, to be marked as InterfaceAudience.Private in 4.0.0.
    org.apache.hadoop.hbase.client.HTableMultiplexer
    since 2.2.0, will be removed in 3.0.0, without replacement. Please use BufferedMutator for batching mutations.
    org.apache.hadoop.hbase.client.HTableMultiplexer.HTableMultiplexerStatus
    since 2.2.0, will be removed in 3.0.0, without replacement. Please use BufferedMutator for batching mutations.
    org.apache.hadoop.hbase.client.ImmutableHColumnDescriptor
    org.apache.hadoop.hbase.client.ImmutableHRegionInfo
    org.apache.hadoop.hbase.client.ImmutableHTableDescriptor
    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.client.replication.ReplicationAdmin
    use Admin instead.
    org.apache.hadoop.hbase.ClusterStatus
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use ClusterMetrics instead.
    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.coprocessor.CoprocessorServiceBackwardCompatiblity
    org.apache.hadoop.hbase.filter.FirstKeyValueMatchingQualifiersFilter
    Deprecated in 2.0.0 and will be removed in 3.0.0.
    org.apache.hadoop.hbase.HColumnDescriptor
    org.apache.hadoop.hbase.HRegionInfo
    As of release 2.0.0, this will be removed in HBase 3.0.0. use RegionInfoBuilder to build RegionInfo.
    org.apache.hadoop.hbase.HTableDescriptor
    As of release 2.0.0, this will be removed in HBase 3.0.0. Use TableDescriptorBuilder to build HTableDescriptor.
    org.apache.hadoop.hbase.ipc.SimpleRpcServer
    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.mapreduce.Import.KeyValueImporter
    Use Import.CellImporter. Will be removed from 3.0 onwards
    org.apache.hadoop.hbase.mapreduce.Import.KeyValueReducer
    Use Import.CellReducer. Will be removed from 3.0 onwards
    org.apache.hadoop.hbase.mapreduce.Import.KeyValueSortImporter
    Use Import.CellSortImporter. Will be removed from 3.0 onwards
    org.apache.hadoop.hbase.mapreduce.Import.KeyValueWritableComparablePartitioner
    Use Import.CellWritableComparablePartitioner. Will be removed from 3.0 onwards
    org.apache.hadoop.hbase.mapreduce.KeyValueSerialization
    Use CellSerialization. Will be removed from 3.0 onwards
    org.apache.hadoop.hbase.mapreduce.KeyValueSortReducer
    Use CellSortReducer. Will be removed from 3.0 onwards
    org.apache.hadoop.hbase.mapreduce.LoadIncrementalHFiles
    As of release 2.0.0, this will be removed in HBase 3.0.0. Use LoadIncrementalHFiles instead.
    org.apache.hadoop.hbase.mapreduce.LoadIncrementalHFiles.LoadQueueItem
    As of release 2.0.0, this will be removed in HBase 3.0.0. Use LoadIncrementalHFiles.LoadQueueItem instead.
    org.apache.hadoop.hbase.master.MirroringTableStateManager
    Since 2.0.0. To be removed in 3.0.0.
    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.RegionLoad
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionMetrics instead.
    org.apache.hadoop.hbase.regionserver.DelimitedKeyPrefixRegionSplitPolicy
    since 2.5.0 and will be removed in 4.0.0. Use RegionSplitRestriction, instead.
    org.apache.hadoop.hbase.regionserver.KeyPrefixRegionSplitPolicy
    since 2.5.0 and will be removed in 4.0.0. Use RegionSplitRestriction, instead.
    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.ServerLoad
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use ServerMetrics instead.
    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.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.types.PBType
    Will be removed in 3.0.0 without replacement. It should not be a public API as it exposes the protobuf stuff. Users who depend on this class should just copy the code your own code base.
    org.apache.hadoop.hbase.util.ByteBufferUtils
    This class will become IA.Private in HBase 3.0. Downstream folks shouldn't use it.
    org.apache.hadoop.hbase.util.CollectionUtils
    Since 2.0.6/2.1.3/2.2.0
    org.apache.hadoop.hbase.util.Counter
    since 2.0.0 and will be removed in 3.0.0. Use LongAdder instead.
    org.apache.hadoop.hbase.util.HBaseFsck
    For removal in hbase-4.0.0. Use HBCK2 instead.
    org.apache.hadoop.hbase.util.hbck.OfflineMetaRepair
    Since 2.0.0. Will be removed in 3.0.0. We've deprecated this tool in hbase-2+ because it destroyed the hbase2 meta table.
    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
  • Deprecated Enums
    Enum
    Description
    org.apache.hadoop.hbase.filter.CompareFilter.CompareOp
    since 2.0.0. Will be removed in 3.0.0. Use CompareOperator instead.
  • Deprecated Exceptions
    Exceptions
    Description
    org.apache.hadoop.hbase.exceptions.PreemptiveFastFailException
    since 2.3.0, and will be removed in 4.0.0.
    org.apache.hadoop.hbase.quotas.ThrottlingException
    replaced by RpcThrottlingException since hbase-2.0.0.
    org.apache.hadoop.hbase.regionserver.RowTooBigException
    since 0.99.0. Use RowTooBigException instead.
  • Deprecated Fields
    Field
    Description
    org.apache.hadoop.hbase.client.Scan.SCAN_ATTRIBUTES_METRICS_DATA
    org.apache.hadoop.hbase.client.Scan.SCAN_ATTRIBUTES_METRICS_ENABLE
    since 1.0.0. Use Scan.setScanMetricsEnabled(boolean)
    org.apache.hadoop.hbase.client.TableDescriptorBuilder.DEFAULT_NORMALIZATION_ENABLED
    org.apache.hadoop.hbase.client.TableDescriptorBuilder.NORMALIZER_TARGET_REGION_SIZE
    org.apache.hadoop.hbase.HConstants.CLUSTER_IS_DISTRIBUTED
    org.apache.hadoop.hbase.HConstants.CP_HTD_ATTR_KEY_PATTERN
    It is used internally. As of release 2.0.0, this will be removed in HBase 3.0.0.
    org.apache.hadoop.hbase.HConstants.CP_HTD_ATTR_VALUE_PARAM_KEY_PATTERN
    It is used internally. As of release 2.0.0, this will be removed in HBase 3.0.0.
    org.apache.hadoop.hbase.HConstants.CP_HTD_ATTR_VALUE_PARAM_PATTERN
    It is used internally. As of release 2.0.0, this will be removed in HBase 3.0.0.
    org.apache.hadoop.hbase.HConstants.CP_HTD_ATTR_VALUE_PARAM_VALUE_PATTERN
    It is used internally. As of release 2.0.0, this will be removed in HBase 3.0.0.
    org.apache.hadoop.hbase.HConstants.CP_HTD_ATTR_VALUE_PATTERN
    It is used internally. As of release 2.0.0, this will be removed in HBase 3.0.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_MASTER_HANLDER_COUNT
    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.HConstants.DEFAULT_ZOOKEPER_CLIENT_PORT
    use HConstants.DEFAULT_ZOOKEEPER_CLIENT_PORT instead
    org.apache.hadoop.hbase.HConstants.DEFAULT_ZOOKEPER_MAX_CLIENT_CNXNS
    use HConstants.DEFAULT_ZOOKEEPER_MAX_CLIENT_CNXNS instead
    org.apache.hadoop.hbase.HConstants.DEFAULT_ZOOKEPER_RECOVERABLE_WAITIME
    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.HConstants.HBASE_REGIONSERVER_LEASE_PERIOD_KEY
    This config option is deprecated. Will be removed at later releases after 0.96.
    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.HConstants.HBASECLIENT_IMPL
    org.apache.hadoop.hbase.HConstants.HBCK_CODE_NAME
    org.apache.hadoop.hbase.HConstants.LIB_DIR
    org.apache.hadoop.hbase.HConstants.LOG_REPLAY_WAIT_REGION_TIMEOUT
    org.apache.hadoop.hbase.HConstants.MASTER_HANDLER_COUNT
    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.HConstants.META_QOS
    the name "META_QOS" is a bit ambiguous, actually only meta region transition can use this priority, and you should not use this directly. Will be removed in 3.0.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.HConstants.OLDEST_TIMESTAMP
    Should not be public since hbase-1.3.0. For internal use only. Move internal to Scanners flagged as special timestamp value never to be returned as timestamp on a Cell.
    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
    moved it into HBaseInterClusterReplicationEndpoint
    org.apache.hadoop.hbase.HConstants.SLOW_LOG_SYS_TABLE_CHORE_DURATION_KEY
    org.apache.hadoop.hbase.HConstants.WEEK_IN_SECONDS
    org.apache.hadoop.hbase.HConstants.ZOOKEEPER_RECOVERABLE_WAITTIME
    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.KeyValue.COMPARATOR
    Use CellComparator.getInstance() instead. Deprecated for hbase 2.0, remove for hbase 3.0.
    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.mapreduce.SimpleTotalOrderPartitioner.END
    since 0.90.0
    org.apache.hadoop.hbase.mapreduce.SimpleTotalOrderPartitioner.START
    since 0.90.0
    org.apache.hadoop.hbase.mapreduce.TableSplit.LOG
    LOG variable would be made private. fix in hbase 3.0
    org.apache.hadoop.hbase.master.LoadBalancer.SYSTEM_TABLES_ON_MASTER
    since 2.4.0, will be removed in 3.0.0.
    org.apache.hadoop.hbase.master.LoadBalancer.TABLES_ON_MASTER
    since 2.4.0, will be removed in 3.0.0.
    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.regionserver.KeyPrefixRegionSplitPolicy.PREFIX_LENGTH_KEY_DEPRECATED
    org.apache.hadoop.hbase.rest.Constants.SCAN_FILTER
    Since 2.4.18/2.5.9/2.6.0, will be removed in 4.0.0. Please use Constants.FILTER instead.
    org.apache.hadoop.hbase.ServerLoad.EMPTY_SERVERLOAD
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use ServerMetricsBuilder.of(ServerName) instead.
    org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils.SNAPSHOT_TIMEOUT_MILLIS_DEFAULT
    Use SnapshotDescriptionUtils.DEFAULT_MAX_WAIT_TIME instead.
    org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils.SNAPSHOT_TIMEOUT_MILLIS_KEY
    Use SnapshotDescriptionUtils.MASTER_SNAPSHOT_TIMEOUT_MILLIS 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.wal.WALEdit.COMPACTION
    Since 2.3.0. Make it protected, internal-use only. Use WALEdit.isCompactionMarker(Cell)
    org.apache.hadoop.hbase.wal.WALEdit.FLUSH
    Since 2.3.0. Make it protected, internal-use only.
    org.apache.hadoop.hbase.wal.WALEdit.METAROW
    Since 2.3.0. Not used.
    org.apache.hadoop.hbase.wal.WALEdit.REGION_EVENT
    Since 2.3.0. Remove. Not for external use. Not used.
    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.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.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.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.zookeeper.ZNodePaths.tableZNode
  • Deprecated Methods
    Method
    Description
    org.apache.hadoop.hbase.AuthUtil.getAuthChore(Configuration)
    Deprecated since 2.2.0, this method will be InterfaceAudience.Private use only after 4.0.0.
    org.apache.hadoop.hbase.Cell.getSequenceId()
    As of HBase-2.0. Will be removed in HBase-3.0.
    org.apache.hadoop.hbase.Cell.getTagsArray()
    As of HBase-2.0. Will be removed in HBase-3.0. Tags are are now internal.
    org.apache.hadoop.hbase.Cell.getTagsLength()
    As of HBase-2.0. Will be removed in HBase-3.0. Tags are are now internal.
    org.apache.hadoop.hbase.Cell.getTagsOffset()
    As of HBase-2.0. Will be removed in HBase-3.0. Tags are are now internal.
    org.apache.hadoop.hbase.Cell.getTypeByte()
    As of HBase-2.0. Will be removed in HBase-3.0. Use Cell.getType().
    org.apache.hadoop.hbase.CellUtil.cloneTags(Cell)
    As of HBase-2.0. Will be removed in HBase-3.0. Use RawCell.cloneTags()
    org.apache.hadoop.hbase.CellUtil.compare(CellComparator, Cell, byte[], int, int)
    As of HBase-2.0. Will be removed in HBase-3.0
    org.apache.hadoop.hbase.CellUtil.copyTagTo(Cell, byte[], int)
    As of HBase-2.0. Will be removed in HBase-3.0.
    org.apache.hadoop.hbase.CellUtil.copyTagTo(Cell, ByteBuffer, int)
    As of HBase-2.0. Will be removed in 3.0.
    org.apache.hadoop.hbase.CellUtil.createCell(byte[])
    As of release 2.0.0, this will be removed in HBase 3.0.0. Use CellBuilder instead
    org.apache.hadoop.hbase.CellUtil.createCell(byte[], byte[])
    As of release 2.0.0, this will be removed in HBase 3.0.0. Use CellBuilder instead
    org.apache.hadoop.hbase.CellUtil.createCell(byte[], byte[], byte[])
    As of release 2.0.0, this will be removed in HBase 3.0.0. Use CellBuilder instead
    org.apache.hadoop.hbase.CellUtil.createCell(byte[], byte[], byte[], long, byte, byte[])
    As of release 2.0.0, this will be removed in HBase 3.0.0. Use CellBuilder instead
    org.apache.hadoop.hbase.CellUtil.createCell(byte[], byte[], byte[], long, byte, byte[], byte[], long)
    As of release 2.0.0, this will be removed in HBase 3.0.0. Use ExtendedCellBuilder instead
    org.apache.hadoop.hbase.CellUtil.createCell(byte[], byte[], byte[], long, byte, byte[], long)
    As of release 2.0.0, this will be removed in HBase 3.0.0. Use ExtendedCellBuilder instead
    org.apache.hadoop.hbase.CellUtil.createCell(byte[], byte[], byte[], long, KeyValue.Type, byte[], byte[])
    As of release 2.0.0, this will be removed in HBase 3.0.0. Use ExtendedCellBuilder instead
    org.apache.hadoop.hbase.CellUtil.createCell(byte[], int, int, byte[], int, int, byte[], int, int)
    As of release 2.0.0, this will be removed in HBase 3.0.0. Use CellBuilder instead
    org.apache.hadoop.hbase.CellUtil.createCell(Cell, byte[])
    As of release 2.0.0, this will be removed in HBase 3.0.0.
    org.apache.hadoop.hbase.CellUtil.createCell(Cell, byte[], byte[])
    As of release 2.0.0, this will be removed in HBase 3.0.0.
    org.apache.hadoop.hbase.CellUtil.createCell(Cell, List<Tag>)
    As of release 2.0.0, this will be removed in HBase 3.0.0.
    org.apache.hadoop.hbase.CellUtil.equalsIgnoreMvccVersion(Cell, Cell)
    As of HBase-2.0. Will be removed in HBase-3.0
    org.apache.hadoop.hbase.CellUtil.estimatedHeapSizeOf(Cell)
    As of release 2.0.0, this will be removed in HBase 3.0.0. Use RawCell.getTags()
    org.apache.hadoop.hbase.CellUtil.estimatedSerializedSizeOf(Cell)
    As of release 2.0.0, this will be removed in HBase 3.0.0.
    org.apache.hadoop.hbase.CellUtil.estimatedSerializedSizeOfKey(Cell)
    As of release 2.0.0, this will be removed in HBase 3.0.0.
    org.apache.hadoop.hbase.CellUtil.fillFamilyRange(Cell, ByteRange)
    As of HBase-2.0. Will be removed in HBase-3.0.
    org.apache.hadoop.hbase.CellUtil.fillQualifierRange(Cell, ByteRange)
    As of HBase-2.0. Will be removed in HBase-3.0.
    org.apache.hadoop.hbase.CellUtil.fillRowRange(Cell, ByteRange)
    As of HBase-2.0. Will be removed in HBase-3.0.
    org.apache.hadoop.hbase.CellUtil.fillTagRange(Cell, ByteRange)
    As of HBase-2.0. Will be removed in HBase-3.0.
    org.apache.hadoop.hbase.CellUtil.fillValueRange(Cell, ByteRange)
    As of HBase-2.0. Will be removed in HBase-3.0.
    org.apache.hadoop.hbase.CellUtil.findCommonPrefixInFlatKey(Cell, Cell, boolean, boolean)
    As of HBase-2.0. Will be removed in HBase-3.0
    org.apache.hadoop.hbase.CellUtil.getCellKeySerializedAsKeyValueKey(Cell)
    As of HBase-2.0. Will be removed in HBase-3.0
    org.apache.hadoop.hbase.CellUtil.getQualifierBufferShallowCopy(Cell)
    As of release 2.0.0, this will be removed in HBase 3.0.0.
    org.apache.hadoop.hbase.CellUtil.getRowByte(Cell, int)
    org.apache.hadoop.hbase.CellUtil.getTag(Cell, byte)
    As of 2.0.0 and will be removed in HBase-3.0.0 Use RawCell.getTag(byte)
    org.apache.hadoop.hbase.CellUtil.getTagArray(Cell)
    As of HBase-2.0. Will be removed in HBase-3.0
    org.apache.hadoop.hbase.CellUtil.getTags(Cell)
    As of 2.0.0 and will be removed in 3.0.0
    org.apache.hadoop.hbase.CellUtil.getValueBufferShallowCopy(Cell)
    As of HBase-2.0. Will be removed in 3.0.
    org.apache.hadoop.hbase.CellUtil.isDelete(byte)
    As of release 2.0.0, this will be removed in HBase 3.0.0.
    org.apache.hadoop.hbase.CellUtil.isDeleteColumnOrFamily(Cell)
    As of release 2.0.0, this will be removed in HBase 3.0.0.
    org.apache.hadoop.hbase.CellUtil.isDeleteColumns(Cell)
    As of release 2.0.0, this will be removed in HBase 3.0.0.
    org.apache.hadoop.hbase.CellUtil.isDeleteColumnVersion(Cell)
    As of release 2.0.0, this will be removed in HBase 3.0.0.
    org.apache.hadoop.hbase.CellUtil.isDeleteFamily(Cell)
    As of release 2.0.0, this will be removed in HBase 3.0.0.
    org.apache.hadoop.hbase.CellUtil.isDeleteFamilyVersion(Cell)
    As of release 2.0.0, this will be removed in HBase 3.0.0.
    org.apache.hadoop.hbase.CellUtil.isDeleteType(Cell)
    As of release 2.0.0, this will be removed in HBase 3.0.0.
    org.apache.hadoop.hbase.CellUtil.matchingColumn(Cell, byte[], int, int, byte[], int, int)
    As of release 2.0.0, this will be removed in HBase 3.0.0.
    org.apache.hadoop.hbase.CellUtil.matchingFamily(Cell, byte[], int, int)
    As of release 2.0.0, this will be removed in HBase 3.0.0.
    org.apache.hadoop.hbase.CellUtil.matchingQualifier(Cell, byte[], int, int)
    As of release 2.0.0, this will be removed in HBase 3.0.0.
    org.apache.hadoop.hbase.CellUtil.matchingRow(Cell, byte[])
    As of release 2.0.0, this will be removed in HBase 3.0.0. Instead use CellUtil.matchingRows(Cell, byte[])
    org.apache.hadoop.hbase.CellUtil.matchingRow(Cell, byte[], int, int)
    As of release 2.0.0, this will be removed in HBase 3.0.0. Instead use CellUtil.matchingRows(Cell, Cell)
    org.apache.hadoop.hbase.CellUtil.matchingRow(Cell, Cell)
    As of release 2.0.0, this will be removed in HBase 3.0.0. Instead use CellUtil.matchingRows(Cell, Cell)
    org.apache.hadoop.hbase.CellUtil.matchingType(Cell, Cell)
    As of HBase-2.0. Will be removed in HBase-3.0
    org.apache.hadoop.hbase.CellUtil.overlappingKeys(byte[], byte[], byte[], byte[])
    As of 2.0.0 and will be removed in 3.0.0
    org.apache.hadoop.hbase.CellUtil.setSequenceId(Cell, long)
    As of HBase-2.0. Will be removed in HBase-3.0
    org.apache.hadoop.hbase.CellUtil.setTimestamp(Cell, byte[], int)
    As of HBase-2.0. Will be a LimitedPrivate API in HBase-3.0.
    org.apache.hadoop.hbase.CellUtil.setTimestamp(Cell, long)
    As of HBase-2.0. Will be a LimitedPrivate API in HBase-3.0.
    org.apache.hadoop.hbase.CellUtil.tagsIterator(byte[], int, int)
    As of 2.0.0 and will be removed in 3.0.0 Instead use PrivateCellUtil.tagsIterator(Cell)
    org.apache.hadoop.hbase.CellUtil.updateLatestStamp(Cell, byte[], int)
    As of HBase-2.0. Will be removed in HBase-3.0
    org.apache.hadoop.hbase.CellUtil.updateLatestStamp(Cell, long)
    As of HBase-2.0. Will be removed in HBase-3.0
    org.apache.hadoop.hbase.CellUtil.writeFlatKey(Cell, DataOutputStream)
    As of HBase-2.0. Will be removed in HBase-3.0
    org.apache.hadoop.hbase.CellUtil.writeRowKeyExcludingCommon(Cell, short, int, DataOutputStream)
    As of HBase-2.0. Will be removed in HBase-3.0
    org.apache.hadoop.hbase.CellUtil.writeRowSkippingBytes(DataOutputStream, Cell, short, int)
    As of 2.0. Will be removed in hbase-3.0
    org.apache.hadoop.hbase.client.Admin.abortProcedure(long, boolean)
    since 2.1.1 and will be removed in 4.0.0.
    org.apache.hadoop.hbase.client.Admin.abortProcedureAsync(long, boolean)
    since 2.1.1 and will be removed in 4.0.0.
    org.apache.hadoop.hbase.client.Admin.addColumn(TableName, ColumnFamilyDescriptor)
    As of release 2.0.0. This will be removed in HBase 3.0.0. Use Admin.addColumnFamily(TableName, ColumnFamilyDescriptor).
    org.apache.hadoop.hbase.client.Admin.balance(boolean)
    Since 2.5.0. Will be removed in 4.0.0. Use Admin.balance(BalanceRequest) instead.
    org.apache.hadoop.hbase.client.Admin.balancer()
    Since 2.0.0. Will be removed in 3.0.0. Use Admin.balance() instead.
    org.apache.hadoop.hbase.client.Admin.balancer(boolean)
    Since 2.0.0. Will be removed in 3.0.0. Use Admin.balance(BalanceRequest) instead.
    org.apache.hadoop.hbase.client.Admin.cloneSnapshot(byte[], TableName)
    since 2.3.0, will be removed in 3.0.0. Use Admin.cloneSnapshot(String, TableName) instead.
    org.apache.hadoop.hbase.client.Admin.closeRegion(byte[], String)
    As of release 2.0.0, this will be removed in HBase 3.0.0. Use Admin.unassign(byte[], boolean).
    org.apache.hadoop.hbase.client.Admin.closeRegion(String, String)
    As of release 2.0.0, this will be removed in HBase 3.0.0. Use Admin.unassign(byte[], boolean).
    org.apache.hadoop.hbase.client.Admin.closeRegion(ServerName, HRegionInfo)
    As of release 2.0.0, this will be removed in HBase 3.0.0 (HBASE-18231). Use Admin.unassign(byte[], boolean).
    org.apache.hadoop.hbase.client.Admin.closeRegionWithEncodedRegionName(String, String)
    As of release 2.0.0, this will be removed in HBase 3.0.0. Use Admin.unassign(byte[], boolean).
    org.apache.hadoop.hbase.client.Admin.compactRegionServer(ServerName, boolean)
    As of release 2.0.0, this will be removed in HBase 3.0.0. Use Admin.compactRegionServer(ServerName) or Admin.majorCompactRegionServer(ServerName).
    org.apache.hadoop.hbase.client.Admin.deleteColumn(TableName, byte[])
    As of release 2.0.0. This will be removed in HBase 3.0.0. Use Admin.deleteColumnFamily(TableName, byte[])}.
    org.apache.hadoop.hbase.client.Admin.deleteSnapshot(byte[])
    Since 2.2.0. Will be removed in 3.0.0. Use Admin.deleteSnapshot(String) instead.
    org.apache.hadoop.hbase.client.Admin.deleteSnapshots(String)
    since 2.0 version and will be removed in 3.0 version. Use Admin.deleteSnapshots(Pattern) instead.
    org.apache.hadoop.hbase.client.Admin.deleteTables(String)
    since 2.0 version and will be removed in 3.0 version This is just a trivial helper method without any magic. Consider using Admin.listTableDescriptors(Pattern) and Admin.deleteTable(TableName)
    org.apache.hadoop.hbase.client.Admin.deleteTables(Pattern)
    since 2.0 version and will be removed in 3.0 version This is just a trivial helper method without any magic. Consider using Admin.listTableDescriptors(java.util.regex.Pattern) and Admin.deleteTable(TableName)
    org.apache.hadoop.hbase.client.Admin.deleteTableSnapshots(String, String)
    since 2.0 version and will be removed in 3.0 version. Use Admin.deleteTableSnapshots(Pattern, Pattern) instead.
    org.apache.hadoop.hbase.client.Admin.disableTables(String)
    since 2.0 version and will be removed in 3.0 version This is just a trivial helper method without any magic. Consider using Admin.listTableDescriptors(Pattern) and Admin.disableTable(org.apache.hadoop.hbase.TableName)
    org.apache.hadoop.hbase.client.Admin.disableTables(Pattern)
    since 2.0 version and will be removed in 3.0 version This is just a trivial helper method without any magic. Consider using Admin.listTableDescriptors(java.util.regex.Pattern) and Admin.disableTable(org.apache.hadoop.hbase.TableName)
    org.apache.hadoop.hbase.client.Admin.enableCatalogJanitor(boolean)
    Since 2.0.0. Will be removed in 3.0.0. Use Admin.catalogJanitorSwitch(boolean)} instead.
    org.apache.hadoop.hbase.client.Admin.enableTables(String)
    since 2.0 version and will be removed in 3.0 version This is just a trivial helper method without any magic. Consider using Admin.listTableDescriptors(Pattern) and Admin.enableTable(org.apache.hadoop.hbase.TableName)
    org.apache.hadoop.hbase.client.Admin.enableTables(Pattern)
    since 2.0 version and will be removed in 3.0 version This is just a trivial helper method without any magic. Consider using Admin.listTableDescriptors(java.util.regex.Pattern) and Admin.enableTable(org.apache.hadoop.hbase.TableName)
    org.apache.hadoop.hbase.client.Admin.execProcedureWithRet(String, String, Map<String, String>)
    Since 2.0.0. Will be removed in 3.0.0. Use Admin.execProcedureWithReturn(String, String, Map) } instead.
    org.apache.hadoop.hbase.client.Admin.getAlterStatus(byte[])
    Since 2.0.0. Will be removed in 3.0.0. No longer needed now you get a Future on an operation.
    org.apache.hadoop.hbase.client.Admin.getAlterStatus(TableName)
    Since 2.0.0. Will be removed in 3.0.0. No longer needed now you get a Future on an operation.
    org.apache.hadoop.hbase.client.Admin.getClusterStatus()
    since 2.0 version and will be removed in 3.0 version. use Admin.getClusterMetrics()
    org.apache.hadoop.hbase.client.Admin.getMasterCoprocessors()
    since 2.0 version and will be removed in 3.0 version. use Admin.getMasterCoprocessorNames()
    org.apache.hadoop.hbase.client.Admin.getOnlineRegions(ServerName)
    As of release 2.0.0, this will be removed in HBase 3.0.0 (HBASE-17980). Use Admin.getRegions(ServerName sn).
    org.apache.hadoop.hbase.client.Admin.getQuotaRetriever(QuotaFilter)
    Since 2.0.0. Will be removed in 3.0.0. Use Admin.getQuota(QuotaFilter).
    org.apache.hadoop.hbase.client.Admin.getSlowLogResponses(Set<ServerName>, LogQueryFilter)
    since 2.4.0 and will be removed in 4.0.0. Use Admin.getLogEntries(Set, String, ServerType, int, Map) instead.
    org.apache.hadoop.hbase.client.Admin.getTableDescriptor(TableName)
    since 2.0 version and will be removed in 3.0 version. Use Admin.getDescriptor(TableName).
    org.apache.hadoop.hbase.client.Admin.getTableDescriptors(List<String>)
    since 2.0 version and will be removed in 3.0 version. use Admin.listTableDescriptors(List)
    org.apache.hadoop.hbase.client.Admin.getTableDescriptorsByTableName(List<TableName>)
    since 2.0 version and will be removed in 3.0 version. use Admin.listTableDescriptors(List)
    org.apache.hadoop.hbase.client.Admin.getTableRegions(TableName)
    As of release 2.0.0, this will be removed in HBase 3.0.0 (HBASE-17980). Use Admin.getRegions(TableName).
    org.apache.hadoop.hbase.client.Admin.isSplitOrMergeEnabled(MasterSwitchType)
    Since 2.0.0. Will be removed in 3.0.0. Use Admin.isSplitEnabled() or Admin.isMergeEnabled() instead.
    org.apache.hadoop.hbase.client.Admin.isTableAvailable(TableName, byte[][])
    Since 2.0.0. Will be removed in 3.0.0. Use Admin.isTableAvailable(TableName)
    org.apache.hadoop.hbase.client.Admin.listSnapshots(String)
    since 2.0 version and will be removed in 3.0 version. Use Admin.listSnapshots(Pattern) instead.
    org.apache.hadoop.hbase.client.Admin.listTableDescriptorsByNamespace(String)
    since 2.0 version and will be removed in 3.0 version. use Admin.listTableDescriptorsByNamespace(byte[])
    org.apache.hadoop.hbase.client.Admin.listTableNames(String)
    since 2.0 version and will be removed in 3.0 version. Use Admin.listTableNames(Pattern) instead.
    org.apache.hadoop.hbase.client.Admin.listTableNames(String, boolean)
    since 2.0 version and will be removed in 3.0 version. Use Admin.listTableNames(Pattern, boolean) instead.
    org.apache.hadoop.hbase.client.Admin.listTables()
    since 2.0 version and will be removed in 3.0 version. Use Admin.listTableDescriptors().
    org.apache.hadoop.hbase.client.Admin.listTables(String)
    since 2.0 version and will be removed in 3.0 version. Use Admin.listTableDescriptors(Pattern) instead.
    org.apache.hadoop.hbase.client.Admin.listTables(String, boolean)
    since 2.0 version and will be removed in 3.0 version. Use Admin.listTableDescriptors(Pattern, boolean).
    org.apache.hadoop.hbase.client.Admin.listTables(Pattern)
    since 2.0 version and will be removed in 3.0 version. Use Admin.listTableDescriptors(java.util.regex.Pattern).
    org.apache.hadoop.hbase.client.Admin.listTables(Pattern, boolean)
    since 2.0 version and will be removed in 3.0 version. Use Admin.listTableDescriptors(java.util.regex.Pattern, boolean).
    org.apache.hadoop.hbase.client.Admin.listTableSnapshots(String, String)
    since 2.0 version and will be removed in 3.0 version. Use Admin.listTableSnapshots(Pattern, Pattern) instead.
    org.apache.hadoop.hbase.client.Admin.mergeRegions(byte[], byte[], boolean)
    Since 2.0. Will be removed in 3.0. Use Admin.mergeRegionsAsync(byte[], byte[], boolean) instead.
    org.apache.hadoop.hbase.client.Admin.mergeRegionsAsync(byte[], byte[], boolean)
    since 2.3.0 and will be removed in 4.0.0. Multi-region merge feature is now supported. Use Admin.mergeRegionsAsync(byte[][], boolean) instead.
    org.apache.hadoop.hbase.client.Admin.modifyColumn(TableName, ColumnFamilyDescriptor)
    As of release 2.0.0. This will be removed in HBase 3.0.0. Use Admin.modifyColumnFamily(TableName, ColumnFamilyDescriptor).
    org.apache.hadoop.hbase.client.Admin.modifyTable(TableName, TableDescriptor)
    since 2.0 version and will be removed in 3.0 version. use Admin.modifyTable(TableDescriptor)
    org.apache.hadoop.hbase.client.Admin.modifyTableAsync(TableName, TableDescriptor)
    since 2.0 version and will be removed in 3.0 version. use Admin.modifyTableAsync(TableDescriptor, boolean)
    org.apache.hadoop.hbase.client.Admin.move(byte[], byte[])
    since 2.2.0 and will be removed in 4.0.0. Use Admin.move(byte[], ServerName) instead. And if you want to move the region to a random server, please use Admin.move(byte[]).
    org.apache.hadoop.hbase.client.Admin.restoreSnapshot(byte[])
    since 2.3.0, will be removed in 3.0.0. Use Admin.restoreSnapshot(String) instead.
    org.apache.hadoop.hbase.client.Admin.restoreSnapshot(byte[], boolean)
    since 2.3.0, will be removed in 3.0.0. Use Admin.restoreSnapshot(String, boolean) instead.
    org.apache.hadoop.hbase.client.Admin.restoreSnapshotAsync(String)
    since 2.3.0, will be removed in 3.0.0. The implementation does not take care of the failsafe property, so do not use it any more.
    org.apache.hadoop.hbase.client.Admin.runCatalogScan()
    Since 2.0.0. Will be removed in 3.0.0. Use Admin.runCatalogJanitor()} instead.
    org.apache.hadoop.hbase.client.Admin.setBalancerRunning(boolean, boolean)
    Since 2.0.0. Will be removed in 3.0.0. Use Admin.balancerSwitch(boolean, boolean) instead.
    org.apache.hadoop.hbase.client.Admin.setCleanerChoreRunning(boolean)
    Since 2.0.0. Will be removed in 3.0.0. Use Admin.cleanerChoreSwitch(boolean)} instead.
    org.apache.hadoop.hbase.client.Admin.setNormalizerRunning(boolean)
    Since 2.0.0. Will be removed in 3.0.0. Use Admin.normalizerSwitch(boolean)} instead.
    org.apache.hadoop.hbase.client.Admin.setSplitOrMergeEnabled(boolean, boolean, MasterSwitchType...)
    Since 2.0.0. Will be removed in 3.0.0. Use Admin.splitSwitch(boolean, boolean) or Admin.mergeSwitch(boolean, boolean) instead.
    org.apache.hadoop.hbase.client.Admin.snapshot(byte[], TableName)
    since 2.3.0, will be removed in 3.0.0. Use Admin.snapshot(String, TableName) instead.
    org.apache.hadoop.hbase.client.Admin.splitRegion(byte[])
    As of release 2.0.0, this will be removed in HBase 3.0.0. Use Admin.splitRegionAsync(byte[], byte[]).
    org.apache.hadoop.hbase.client.Admin.splitRegion(byte[], byte[])
    As of release 2.0.0, this will be removed in HBase 3.0.0. Use Admin.splitRegionAsync(byte[], byte[]).
    org.apache.hadoop.hbase.client.Admin.takeSnapshotAsync(SnapshotDescription)
    Since 2.0.0. Will be removed in 3.0.0. Use Admin.snapshotAsync(SnapshotDescription) instead.
    org.apache.hadoop.hbase.client.Admin.unassign(byte[], boolean)
    since 2.4.0 and will be removed in 4.0.0. Use Admin.unassign(byte[]) instead.
    org.apache.hadoop.hbase.client.Append.add(byte[], byte[], byte[])
    As of release 2.0.0, this will be removed in HBase 3.0.0. Use Append.addColumn(byte[], byte[], byte[]) instead
    org.apache.hadoop.hbase.client.Append.setFamilyCellMap(NavigableMap<byte[], List<Cell>>)
    As of release 2.0.0, this will be removed in HBase 3.0.0. Use Append(byte[], long, NavigableMap) instead
    org.apache.hadoop.hbase.client.AsyncAdmin.abortProcedure(long, boolean)
    since 2.1.1 and will be removed in 4.0.0.
    org.apache.hadoop.hbase.client.AsyncAdmin.balance(boolean)
    Since 2.5.0. Will be removed in 4.0.0. Use AsyncAdmin.balance(BalanceRequest) instead.
    org.apache.hadoop.hbase.client.AsyncAdmin.getSlowLogResponses(Set<ServerName>, LogQueryFilter)
    since 2.4.0 and will be removed in 4.0.0. Use AsyncAdmin.getLogEntries(Set, String, ServerType, int, Map) instead.
    org.apache.hadoop.hbase.client.AsyncAdmin.isTableAvailable(TableName, byte[][])
    Since 2.2.0. Will be removed in 3.0.0. Use AsyncAdmin.isTableAvailable(TableName)
    org.apache.hadoop.hbase.client.AsyncAdmin.mergeRegions(byte[], byte[], boolean)
    since 2.3.0 and will be removed in 4.0.0.Use AsyncAdmin.mergeRegions(List, boolean) instead.
    org.apache.hadoop.hbase.client.AsyncAdmin.unassign(byte[], boolean)
    since 2.4.0 and will be removed in 4.0.0. Use AsyncAdmin.unassign(byte[]) instead.
    org.apache.hadoop.hbase.client.AsyncAdminBuilder.setRetryPauseForCQTBE(long, TimeUnit)
    Since 2.5.0, will be removed in 4.0.0. Please use AsyncAdminBuilder.setRetryPauseForServerOverloaded(long, TimeUnit) instead.
    org.apache.hadoop.hbase.client.AsyncTable.checkAndMutate(byte[], byte[])
    Since 2.4.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.checkAndMutate(byte[], Filter)
    Since 2.4.0, will be removed in 4.0.0. For internal test use only, do not use it any more.
    org.apache.hadoop.hbase.client.AsyncTableBuilder.setRetryPauseForCQTBE(long, TimeUnit)
    Since 2.5.0, will be removed in 4.0.0. Please use AsyncTableBuilder.setRetryPauseForServerOverloaded(long, TimeUnit) instead.
    org.apache.hadoop.hbase.client.BufferedMutatorParams.opertationTimeout(int)
    Since 2.3.0, will be removed in 4.0.0. Use BufferedMutatorParams.operationTimeout(int)
    org.apache.hadoop.hbase.client.ClusterConnection.clearRegionCache()
    Connection.clearRegionLocationCache() instead.
    org.apache.hadoop.hbase.client.ClusterConnection.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.Delete.addDeleteMarker(Cell)
    As of release 2.0.0, this will be removed in HBase 3.0.0. Use Delete.add(Cell) instead
    org.apache.hadoop.hbase.client.Delete.setFamilyCellMap(NavigableMap<byte[], List<Cell>>)
    As of release 2.0.0, this will be removed in HBase 3.0.0. Use Delete(byte[], long, NavigableMap) instead
    org.apache.hadoop.hbase.client.Get.isClosestRowBefore()
    since 2.0.0 and will be removed in 3.0.0
    org.apache.hadoop.hbase.client.Get.setClosestRowBefore(boolean)
    since 2.0.0 and will be removed in 3.0.0
    org.apache.hadoop.hbase.client.Get.setMaxVersions()
    It is easy to misunderstand with column family's max versions, so use Get.readAllVersions() instead.
    org.apache.hadoop.hbase.client.Get.setMaxVersions(int)
    It is easy to misunderstand with column family's max versions, so use Get.readVersions(int) instead.
    org.apache.hadoop.hbase.client.Get.setTimeStamp(long)
    As of release 2.0.0, this will be removed in HBase 3.0.0. Use Get.setTimestamp(long) instead
    org.apache.hadoop.hbase.client.HBaseAdmin.closeRegion(byte[], String)
    org.apache.hadoop.hbase.client.HBaseAdmin.closeRegion(String, String)
    org.apache.hadoop.hbase.client.HBaseAdmin.closeRegion(ServerName, HRegionInfo)
    org.apache.hadoop.hbase.client.HBaseAdmin.closeRegionWithEncodedRegionName(String, String)
    org.apache.hadoop.hbase.client.HBaseAdmin.deleteColumn(TableName, byte[])
    Since 2.0. Will be removed in 3.0. Use Admin.deleteColumnFamily(TableName, byte[]) instead.
    org.apache.hadoop.hbase.client.HBaseAdmin.getOnlineRegions(ServerName)
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use HBaseAdmin.getRegions(ServerName).
    org.apache.hadoop.hbase.client.HBaseAdmin.getTableRegions(TableName)
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use HBaseAdmin.getRegions(TableName).
    org.apache.hadoop.hbase.client.HBaseAdmin.mergeRegions(byte[], byte[], boolean)
    Since 2.0. Will be removed in 3.0. Use Admin.mergeRegionsAsync(byte[], byte[], boolean) instead.
    org.apache.hadoop.hbase.client.Hbck.scheduleServerCrashProcedure(List<HBaseProtos.ServerName>)
    since 2.2.1. Will removed in 3.0.0.
    org.apache.hadoop.hbase.client.HTable.checkAndDelete(byte[], byte[], byte[], byte[], Delete)
    org.apache.hadoop.hbase.client.HTable.checkAndDelete(byte[], byte[], byte[], CompareOperator, byte[], Delete)
    org.apache.hadoop.hbase.client.HTable.checkAndDelete(byte[], byte[], byte[], CompareFilter.CompareOp, byte[], Delete)
    org.apache.hadoop.hbase.client.HTable.checkAndMutate(byte[], byte[])
    org.apache.hadoop.hbase.client.HTable.checkAndMutate(byte[], byte[], byte[], CompareOperator, byte[], RowMutations)
    org.apache.hadoop.hbase.client.HTable.checkAndMutate(byte[], byte[], byte[], CompareFilter.CompareOp, byte[], RowMutations)
    org.apache.hadoop.hbase.client.HTable.checkAndMutate(byte[], Filter)
    org.apache.hadoop.hbase.client.HTable.checkAndPut(byte[], byte[], byte[], byte[], Put)
    org.apache.hadoop.hbase.client.HTable.checkAndPut(byte[], byte[], byte[], CompareOperator, byte[], Put)
    org.apache.hadoop.hbase.client.HTable.checkAndPut(byte[], byte[], byte[], CompareFilter.CompareOp, byte[], Put)
    org.apache.hadoop.hbase.client.HTable.getOperationTimeout()
    org.apache.hadoop.hbase.client.HTable.getReadRpcTimeout()
    org.apache.hadoop.hbase.client.HTable.getRpcTimeout()
    org.apache.hadoop.hbase.client.HTable.getTableDescriptor()
    org.apache.hadoop.hbase.client.HTable.getWriteRpcTimeout()
    org.apache.hadoop.hbase.client.HTable.setOperationTimeout(int)
    org.apache.hadoop.hbase.client.HTable.setReadRpcTimeout(int)
    org.apache.hadoop.hbase.client.HTable.setRpcTimeout(int)
    org.apache.hadoop.hbase.client.HTable.setWriteRpcTimeout(int)
    org.apache.hadoop.hbase.client.HTableMultiplexer.put(byte[], List<Put>)
    Use HTableMultiplexer.put(TableName, List) instead.
    org.apache.hadoop.hbase.client.HTableMultiplexer.put(byte[], Put)
    Use HTableMultiplexer.put(TableName, Put) instead.
    org.apache.hadoop.hbase.client.HTableMultiplexer.put(byte[], Put, int)
    Use HTableMultiplexer.put(TableName, Put) instead.
    org.apache.hadoop.hbase.client.ImmutableScan.isSmall()
    org.apache.hadoop.hbase.client.ImmutableScan.setAsyncPrefetch(boolean)
    org.apache.hadoop.hbase.client.ImmutableScan.setSmall(boolean)
    org.apache.hadoop.hbase.client.ImmutableScan.setTimeStamp(long)
    org.apache.hadoop.hbase.client.Increment.equals(Object)
    As of release 2.0.0, this will be removed in HBase 3.0.0. Use Row.COMPARATOR instead
    org.apache.hadoop.hbase.client.Increment.hashCode()
    As of release 2.0.0, this will be removed in HBase 3.0.0. No replacement.
    org.apache.hadoop.hbase.client.Increment.setFamilyCellMap(NavigableMap<byte[], List<Cell>>)
    As of release 2.0.0, this will be removed in HBase 3.0.0. Use Increment(byte[], long, NavigableMap) instead
    org.apache.hadoop.hbase.client.Mutation.compareTo(Row)
    As of release 2.0.0, this will be removed in HBase 3.0.0. Use Row.COMPARATOR instead
    org.apache.hadoop.hbase.client.Mutation.getTimeStamp()
    As of release 2.0.0, this will be removed in HBase 3.0.0. Use Mutation.getTimestamp() instead
    org.apache.hadoop.hbase.client.Mutation.setFamilyCellMap(NavigableMap<byte[], List<Cell>>)
    As of release 2.0.0, this will be removed in HBase 3.0.0. Use Mutation(byte[], long, NavigableMap) instead
    org.apache.hadoop.hbase.client.Put.addImmutable(byte[], byte[], byte[])
    As of release 2.0.0, this will be removed in HBase 3.0.0. Use Put.add(Cell) and CellBuilder instead
    org.apache.hadoop.hbase.client.Put.addImmutable(byte[], byte[], long, byte[])
    As of release 2.0.0, this will be removed in HBase 3.0.0. Use Put.add(Cell) and CellBuilder instead
    org.apache.hadoop.hbase.client.Put.addImmutable(byte[], ByteBuffer, long, ByteBuffer)
    As of release 2.0.0, this will be removed in HBase 3.0.0. Use Put.add(Cell) and CellBuilder instead
    org.apache.hadoop.hbase.client.Put.setFamilyCellMap(NavigableMap<byte[], List<Cell>>)
    As of release 2.0.0, this will be removed in HBase 3.0.0. Use Put(byte[], long, NavigableMap) instead
    org.apache.hadoop.hbase.client.RegionInfo.isOffline()
    since 3.0.0 and will be removed in 4.0.0
    org.apache.hadoop.hbase.client.RegionInfo.isSplitParent()
    since 3.0.0 and will be removed in 4.0.0, Use RegionInfo.isSplit() instead.
    org.apache.hadoop.hbase.client.RegionInfoBuilder.setOffline(boolean)
    org.apache.hadoop.hbase.client.RegionLoadStats.getMemstoreLoad()
    As of release 2.0.0, this will be removed in HBase 3.0.0. Use RegionLoadStats.getMemStoreLoad() instead
    org.apache.hadoop.hbase.client.replication.ReplicationAdmin.addPeer(String, ReplicationPeerConfig)
    use Admin.addReplicationPeer(String, ReplicationPeerConfig) instead
    org.apache.hadoop.hbase.client.replication.ReplicationAdmin.addPeer(String, ReplicationPeerConfig, Map<TableName, ? extends Collection<String>>)
    as release of 2.0.0, and it will be removed in 3.0.0, use ReplicationAdmin.addPeer(String, ReplicationPeerConfig) instead.
    org.apache.hadoop.hbase.client.replication.ReplicationAdmin.appendPeerTableCFs(String, String)
    as release of 2.0.0, and it will be removed in 3.0.0, use ReplicationAdmin.appendPeerTableCFs(String, Map) instead.
    org.apache.hadoop.hbase.client.replication.ReplicationAdmin.appendPeerTableCFs(String, Map<TableName, ? extends Collection<String>>)
    org.apache.hadoop.hbase.client.replication.ReplicationAdmin.disablePeer(String)
    use Admin.disableReplicationPeer(String) instead
    org.apache.hadoop.hbase.client.replication.ReplicationAdmin.disableTableRep(TableName)
    use Admin.disableTableReplication(TableName) instead
    org.apache.hadoop.hbase.client.replication.ReplicationAdmin.enablePeer(String)
    use Admin.enableReplicationPeer(String) instead
    org.apache.hadoop.hbase.client.replication.ReplicationAdmin.enableTableRep(TableName)
    use Admin.enableTableReplication(TableName) instead
    org.apache.hadoop.hbase.client.replication.ReplicationAdmin.getPeerConfig(String)
    use Admin.getReplicationPeerConfig(String) instead
    org.apache.hadoop.hbase.client.replication.ReplicationAdmin.getPeersCount()
     
    org.apache.hadoop.hbase.client.replication.ReplicationAdmin.getPeerState(String)
    org.apache.hadoop.hbase.client.replication.ReplicationAdmin.getPeerTableCFs(String)
    as release of 2.0.0, and it will be removed in 3.0.0, use ReplicationAdmin.getPeerConfig(String) instead.
    org.apache.hadoop.hbase.client.replication.ReplicationAdmin.listPeerConfigs()
    use Admin.listReplicationPeers() instead
    org.apache.hadoop.hbase.client.replication.ReplicationAdmin.listReplicated()
    use Admin.listReplicatedTableCFs() instead
    org.apache.hadoop.hbase.client.replication.ReplicationAdmin.parseTableCFsFromConfig(String)
    as release of 2.0.0, and it will be removed in 3.0.0
    org.apache.hadoop.hbase.client.replication.ReplicationAdmin.removePeer(String)
    use Admin.removeReplicationPeer(String) instead
    org.apache.hadoop.hbase.client.replication.ReplicationAdmin.removePeerTableCFs(String, String)
    as release of 2.0.0, and it will be removed in 3.0.0, use ReplicationAdmin.removePeerTableCFs(String, Map) instead.
    org.apache.hadoop.hbase.client.replication.ReplicationAdmin.removePeerTableCFs(String, Map<TableName, ? extends Collection<String>>)
    org.apache.hadoop.hbase.client.replication.ReplicationAdmin.setPeerTableCFs(String, Map<TableName, ? extends Collection<String>>)
    org.apache.hadoop.hbase.client.replication.ReplicationAdmin.updatePeerConfig(String, ReplicationPeerConfig)
    use Admin.updateReplicationPeerConfig(String, ReplicationPeerConfig) instead
    org.apache.hadoop.hbase.client.Result.isPartial()
    the word 'partial' ambiguous, use Result.mayHaveMoreCellsInRow() instead. Deprecated since 1.4.0.
    org.apache.hadoop.hbase.client.Row.compareTo(Row)
    As of release 2.0.0, this will be removed in HBase 3.0.0. Use Row.COMPARATOR instead
    org.apache.hadoop.hbase.client.RowMutations.add(Delete)
    since 2.0 version and will be removed in 3.0 version. use RowMutations.add(Mutation)
    org.apache.hadoop.hbase.client.RowMutations.add(Put)
    since 2.0 version and will be removed in 3.0 version. use RowMutations.add(Mutation)
    org.apache.hadoop.hbase.client.RowMutations.compareTo(Row)
    As of release 2.0.0, this will be removed in HBase 3.0.0. Use Row.COMPARATOR instead
    org.apache.hadoop.hbase.client.RowMutations.equals(Object)
    As of release 2.0.0, this will be removed in HBase 3.0.0. No replacement
    org.apache.hadoop.hbase.client.RowMutations.hashCode()
    As of release 2.0.0, this will be removed in HBase 3.0.0. No replacement
    org.apache.hadoop.hbase.client.Scan.getScanMetrics()
    Use ResultScanner.getScanMetrics() instead. And notice that, please do not use this method and ResultScanner.getScanMetrics() together, the metrics will be messed up.
    org.apache.hadoop.hbase.client.Scan.isSmall()
    since 2.0.0 and will be removed in 3.0.0. See the comment of Scan.setSmall(boolean)
    org.apache.hadoop.hbase.client.Scan.setMaxVersions()
    since 2.0.0 and will be removed in 3.0.0. It is easy to misunderstand with column family's max versions, so use Scan.readAllVersions() instead.
    org.apache.hadoop.hbase.client.Scan.setMaxVersions(int)
    since 2.0.0 and will be removed in 3.0.0. It is easy to misunderstand with column family's max versions, so use Scan.readVersions(int) instead.
    org.apache.hadoop.hbase.client.Scan.setRowPrefixFilter(byte[])
    since 2.5.0, will be removed in 4.0.0. The name of this method is considered to be confusing as it does not use a Filter but uses setting the startRow and stopRow instead. Use Scan.setStartStopRowForPrefixScan(byte[]) instead.
    org.apache.hadoop.hbase.client.Scan.setSmall(boolean)
    since 2.0.0 and will be removed in 3.0.0. Use Scan.setLimit(int) and Scan.setReadType(ReadType) instead. And for the one rpc optimization, now we will also fetch data when openScanner, and if the number of rows reaches the limit then we will close the scanner automatically which means we will fall back to one rpc.
    org.apache.hadoop.hbase.client.Scan.setStartRow(byte[])
    since 2.0.0 and will be removed in 3.0.0. Use Scan.withStartRow(byte[]) instead. This method may change the inclusive of the stop row to keep compatible with the old behavior.
    org.apache.hadoop.hbase.client.Scan.setStopRow(byte[])
    since 2.0.0 and will be removed in 3.0.0. Use Scan.withStopRow(byte[]) instead. This method may change the inclusive of the stop row to keep compatible with the old behavior.
    org.apache.hadoop.hbase.client.Scan.setTimeStamp(long)
    As of release 2.0.0, this will be removed in HBase 3.0.0. Use Scan.setTimestamp(long) instead
    org.apache.hadoop.hbase.client.SnapshotDescription.getTable()
    since 2.0.0 and will be removed in 3.0.0. Use SnapshotDescription.getTableName() or SnapshotDescription.getTableNameAsString() instead.
    org.apache.hadoop.hbase.client.Table.checkAndDelete(byte[], byte[], byte[], byte[], Delete)
    Since 2.0.0. Will be removed in 3.0.0. Use Table.checkAndMutate(byte[], byte[])
    org.apache.hadoop.hbase.client.Table.checkAndDelete(byte[], byte[], byte[], CompareOperator, byte[], Delete)
    Since 2.0.0. Will be removed in 3.0.0. Use Table.checkAndMutate(byte[], byte[])
    org.apache.hadoop.hbase.client.Table.checkAndDelete(byte[], byte[], byte[], CompareFilter.CompareOp, byte[], Delete)
    Since 2.0.0. Will be removed in 3.0.0. Use Table.checkAndMutate(byte[], byte[])
    org.apache.hadoop.hbase.client.Table.checkAndMutate(byte[], byte[])
    Since 2.4.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.checkAndMutate(byte[], byte[], byte[], CompareOperator, byte[], RowMutations)
    Since 2.0.0. Will be removed in 3.0.0. Use Table.checkAndMutate(byte[], byte[])
    org.apache.hadoop.hbase.client.Table.checkAndMutate(byte[], byte[], byte[], CompareFilter.CompareOp, byte[], RowMutations)
    Since 2.0.0. Will be removed in 3.0.0. Use Table.checkAndMutate(byte[], byte[])
    org.apache.hadoop.hbase.client.Table.checkAndMutate(byte[], Filter)
    Since 2.4.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.checkAndPut(byte[], byte[], byte[], byte[], Put)
    Since 2.0.0. Will be removed in 3.0.0. Use Table.checkAndMutate(byte[], byte[])
    org.apache.hadoop.hbase.client.Table.checkAndPut(byte[], byte[], byte[], CompareOperator, byte[], Put)
    Since 2.0.0. Will be removed in 3.0.0. Use Table.checkAndMutate(byte[], byte[])
    org.apache.hadoop.hbase.client.Table.checkAndPut(byte[], byte[], byte[], CompareFilter.CompareOp, byte[], Put)
    Since 2.0.0. Will be removed in 3.0.0. Use Table.checkAndMutate(byte[], byte[])
    org.apache.hadoop.hbase.client.Table.existsAll(List<Get>)
    since 2.0 version and will be removed in 3.0 version. use Table.exists(List)
    org.apache.hadoop.hbase.client.Table.getOperationTimeout()
    since 2.0 and will be removed in 3.0 version use Table.getOperationTimeout(TimeUnit) instead
    org.apache.hadoop.hbase.client.Table.getReadRpcTimeout()
    since 2.0 and will be removed in 3.0 version use Table.getReadRpcTimeout(TimeUnit) instead
    org.apache.hadoop.hbase.client.Table.getRpcTimeout()
    use Table.getReadRpcTimeout(TimeUnit) or Table.getWriteRpcTimeout(TimeUnit) instead
    org.apache.hadoop.hbase.client.Table.getTableDescriptor()
    since 2.0 version and will be removed in 3.0 version. use Table.getDescriptor()
    org.apache.hadoop.hbase.client.Table.getWriteRpcTimeout()
    since 2.0 and will be removed in 3.0 version use Table.getWriteRpcTimeout(TimeUnit) instead
    org.apache.hadoop.hbase.client.Table.setOperationTimeout(int)
    since 2.0.0, use TableBuilder.setOperationTimeout(int) instead
    org.apache.hadoop.hbase.client.Table.setReadRpcTimeout(int)
    since 2.0.0, use TableBuilder.setReadRpcTimeout(int) instead
    org.apache.hadoop.hbase.client.Table.setRpcTimeout(int)
    Use setReadRpcTimeout or setWriteRpcTimeout instead
    org.apache.hadoop.hbase.client.Table.setWriteRpcTimeout(int)
    since 2.0.0, use TableBuilder.setWriteRpcTimeout(int) instead
    org.apache.hadoop.hbase.client.TableDescriptor.getCoprocessors()
    As of release 2.0.0, this will be removed in HBase 3.0.0. Use TableDescriptor.getCoprocessorDescriptors() instead
    org.apache.hadoop.hbase.client.TableDescriptor.getOwnerString()
    since 2.0.0 and will be removed in 3.0.0.
    org.apache.hadoop.hbase.client.TableDescriptorBuilder.addColumnFamily(ColumnFamilyDescriptor)
    As of release 2.0.0, this will be removed in HBase 3.0.0. Use TableDescriptorBuilder.setColumnFamily(ColumnFamilyDescriptor) instead
    org.apache.hadoop.hbase.client.TableDescriptorBuilder.addCoprocessor(String)
    As of release 2.0.0, this will be removed in HBase 3.0.0. Use TableDescriptorBuilder.setCoprocessor(String) instead
    org.apache.hadoop.hbase.client.TableDescriptorBuilder.addCoprocessor(String, Path, int, Map<String, String>)
    As of release 2.0.0, this will be removed in HBase 3.0.0. Use TableDescriptorBuilder.setCoprocessor(CoprocessorDescriptor) instead
    org.apache.hadoop.hbase.client.TableDescriptorBuilder.addCoprocessorWithSpec(String)
    As of release 2.0.0, this will be removed in HBase 3.0.0. Use TableDescriptorBuilder.setCoprocessor(CoprocessorDescriptor) instead
    org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor.getOwnerString()
    since 2.0.0 and will be removed in 3.0.0.
    org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor.setCoprocessorWithSpec(String)
    used by HTableDescriptor and admin.rb. As of release 2.0.0, this will be removed in HBase 3.0.0.
    org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor.setOwner(User)
    since 2.0.0 and will be removed in 3.0.0.
    org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor.setOwnerString(String)
    since 2.0.0 and will be removed in 3.0.0.
    org.apache.hadoop.hbase.client.TableDescriptorBuilder.setOwner(User)
    since 2.0.0 and will be removed in 3.0.0.
    org.apache.hadoop.hbase.client.TableDescriptorBuilder.setOwnerString(String)
    since 2.0.0 and will be removed in 3.0.0.
    org.apache.hadoop.hbase.ClusterStatus.getBackupMasters()
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use ClusterStatus.getBackupMasterNames() instead.
    org.apache.hadoop.hbase.ClusterStatus.getBackupMastersSize()
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use ClusterStatus.getBackupMasterNames() instead.
    org.apache.hadoop.hbase.ClusterStatus.getDeadServers()
    As of release 2.0.0, this will be removed in HBase 3.0.0 (HBASE-13656). Use ClusterStatus.getDeadServerNames().
    org.apache.hadoop.hbase.ClusterStatus.getDeadServersSize()
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use ClusterStatus.getDeadServerNames().
    org.apache.hadoop.hbase.ClusterStatus.getLastMajorCompactionTsForRegion(byte[])
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use ClusterMetrics.getLastMajorCompactionTimestamp(byte[]) instead.
    org.apache.hadoop.hbase.ClusterStatus.getLastMajorCompactionTsForTable(TableName)
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use ClusterMetrics.getLastMajorCompactionTimestamp(TableName) instead.
    org.apache.hadoop.hbase.ClusterStatus.getLoad(ServerName)
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use ClusterStatus.getLiveServerMetrics() instead.
    org.apache.hadoop.hbase.ClusterStatus.getMaster()
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use ClusterStatus.getMasterName() instead.
    org.apache.hadoop.hbase.ClusterStatus.getMasterCoprocessors()
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use ClusterStatus.getMasterCoprocessorNames() instead.
    org.apache.hadoop.hbase.ClusterStatus.getRegionsCount()
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use ClusterMetrics.getRegionCount().
    org.apache.hadoop.hbase.ClusterStatus.getRequestsCount()
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use ClusterMetrics.getRequestCount() instead.
    org.apache.hadoop.hbase.ClusterStatus.getServers()
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use ClusterStatus.getLiveServerMetrics() instead.
    org.apache.hadoop.hbase.ClusterStatus.getServersSize()
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use ClusterStatus.getLiveServerMetrics().
    org.apache.hadoop.hbase.ClusterStatus.getVersion()
    As of release 2.0.0, this will be removed in HBase 3.0.0
    org.apache.hadoop.hbase.ClusterStatus.isBalancerOn()
    As of release 2.0.0, this will be removed in HBase 3.0.0 No flag in 2.0
    org.apache.hadoop.hbase.coprocessor.MasterObserver.postCompletedModifyTableAction(ObserverContext<MasterCoprocessorEnvironment>, TableName, TableDescriptor)
    Since 2.1. Will be removed in 3.0.
    org.apache.hadoop.hbase.coprocessor.MasterObserver.postModifyNamespace(ObserverContext<MasterCoprocessorEnvironment>, NamespaceDescriptor)
    Since 2.1. Will be removed in 3.0.
    org.apache.hadoop.hbase.coprocessor.MasterObserver.postModifyTable(ObserverContext<MasterCoprocessorEnvironment>, TableName, TableDescriptor)
    Since 2.1. Will be removed in 3.0.
    org.apache.hadoop.hbase.coprocessor.MasterObserver.postUnassign(ObserverContext<MasterCoprocessorEnvironment>, RegionInfo, boolean)
    in 2.4.0. replaced by postUnassign(ctx, regionInfo). removed in hbase 3. until then safe to either leave implementation here or move it to the new method. default impl of that method calls this one.
    org.apache.hadoop.hbase.coprocessor.MasterObserver.preModifyNamespace(ObserverContext<MasterCoprocessorEnvironment>, NamespaceDescriptor)
    Since 2.1. Will be removed in 3.0.
    org.apache.hadoop.hbase.coprocessor.MasterObserver.preModifyTable(ObserverContext<MasterCoprocessorEnvironment>, TableName, TableDescriptor)
    Since 2.1. Will be removed in 3.0.
    org.apache.hadoop.hbase.coprocessor.MasterObserver.preModifyTableAction(ObserverContext<MasterCoprocessorEnvironment>, TableName, TableDescriptor)
    Since 2.1. Will be removed in 3.0.
    org.apache.hadoop.hbase.coprocessor.MasterObserver.preUnassign(ObserverContext<MasterCoprocessorEnvironment>, RegionInfo, boolean)
    in 2.4.0. replaced by preUnassign(ctx, regionInfo). removed in hbase 3. until then safe to either leave implementation here or move it to the new method. default impl of that method calls this one.
    org.apache.hadoop.hbase.coprocessor.ObserverContextImpl.createAndPrepare(E)
    org.apache.hadoop.hbase.coprocessor.RegionObserver.postAppend(ObserverContext<RegionCoprocessorEnvironment>, Append, Result)
    since 2.5.0 and will be removed in 4.0.0. Use RegionObserver.postAppend(ObserverContext, Append, Result, WALEdit) instead.
    org.apache.hadoop.hbase.coprocessor.RegionObserver.postCheckAndDelete(ObserverContext<RegionCoprocessorEnvironment>, byte[], byte[], byte[], CompareOperator, ByteArrayComparable, Delete, boolean)
    since 2.4.0 and will be removed in 4.0.0. Use RegionObserver.postCheckAndMutate(ObserverContext, CheckAndMutate, CheckAndMutateResult) instead.
    org.apache.hadoop.hbase.coprocessor.RegionObserver.postCheckAndDelete(ObserverContext<RegionCoprocessorEnvironment>, byte[], Filter, Delete, boolean)
    since 2.4.0 and will be removed in 4.0.0. Use RegionObserver.postCheckAndMutate(ObserverContext, CheckAndMutate, CheckAndMutateResult) instead.
    org.apache.hadoop.hbase.coprocessor.RegionObserver.postCheckAndPut(ObserverContext<RegionCoprocessorEnvironment>, byte[], byte[], byte[], CompareOperator, ByteArrayComparable, Put, boolean)
    since 2.4.0 and will be removed in 4.0.0. Use RegionObserver.postCheckAndMutate(ObserverContext, CheckAndMutate, CheckAndMutateResult) instead.
    org.apache.hadoop.hbase.coprocessor.RegionObserver.postCheckAndPut(ObserverContext<RegionCoprocessorEnvironment>, byte[], Filter, Put, boolean)
    since 2.4.0 and will be removed in 4.0.0. Use RegionObserver.postCheckAndMutate(ObserverContext, CheckAndMutate, CheckAndMutateResult) instead.
    org.apache.hadoop.hbase.coprocessor.RegionObserver.postDelete(ObserverContext<RegionCoprocessorEnvironment>, Delete, WALEdit, Durability)
    since 2.5.0 and will be removed in 4.0.0. Use RegionObserver.postDelete(ObserverContext, Delete, WALEdit) instead.
    org.apache.hadoop.hbase.coprocessor.RegionObserver.postIncrement(ObserverContext<RegionCoprocessorEnvironment>, Increment, Result)
    since 2.5.0 and will be removed in 4.0.0. Use RegionObserver.postIncrement(ObserverContext, Increment, Result, WALEdit) instead.
    org.apache.hadoop.hbase.coprocessor.RegionObserver.postInstantiateDeleteTracker(ObserverContext<RegionCoprocessorEnvironment>, DeleteTracker)
    Since 2.0 with out any replacement and will be removed in 3.0
    org.apache.hadoop.hbase.coprocessor.RegionObserver.postMutationBeforeWAL(ObserverContext<RegionCoprocessorEnvironment>, RegionObserver.MutationType, Mutation, Cell, Cell)
    since 2.2.0 and will be removedin 4.0.0. Use RegionObserver.postIncrementBeforeWAL(ObserverContext, Mutation, List) or RegionObserver.postAppendBeforeWAL(ObserverContext, Mutation, List) instead.
    org.apache.hadoop.hbase.coprocessor.RegionObserver.postPut(ObserverContext<RegionCoprocessorEnvironment>, Put, WALEdit, Durability)
    since 2.5.0 and will be removed in 4.0.0. Use RegionObserver.postPut(ObserverContext, Put, WALEdit) instead.
    org.apache.hadoop.hbase.coprocessor.RegionObserver.postStoreFileReaderOpen(ObserverContext<RegionCoprocessorEnvironment>, FileSystem, Path, FSDataInputStreamWrapper, long, CacheConfig, Reference, StoreFileReader)
    For Phoenix only, StoreFileReader is not a stable interface.
    org.apache.hadoop.hbase.coprocessor.RegionObserver.preAppend(ObserverContext<RegionCoprocessorEnvironment>, Append)
    since 2.5.0 and will be removed in 4.0.0. Use RegionObserver.preAppend(ObserverContext, Append, WALEdit) instead.
    org.apache.hadoop.hbase.coprocessor.RegionObserver.preAppendAfterRowLock(ObserverContext<RegionCoprocessorEnvironment>, Append)
    since 2.5.0 and will be removed in 4.0.0. Use RegionObserver.preBatchMutate(ObserverContext, MiniBatchOperationInProgress) instead.
    org.apache.hadoop.hbase.coprocessor.RegionObserver.preCheckAndDelete(ObserverContext<RegionCoprocessorEnvironment>, byte[], byte[], byte[], CompareOperator, ByteArrayComparable, Delete, boolean)
    since 2.4.0 and will be removed in 4.0.0. Use RegionObserver.preCheckAndMutate(ObserverContext, CheckAndMutate, CheckAndMutateResult) instead.
    org.apache.hadoop.hbase.coprocessor.RegionObserver.preCheckAndDelete(ObserverContext<RegionCoprocessorEnvironment>, byte[], Filter, Delete, boolean)
    since 2.4.0 and will be removed in 4.0.0. Use RegionObserver.preCheckAndMutate(ObserverContext, CheckAndMutate, CheckAndMutateResult) instead.
    org.apache.hadoop.hbase.coprocessor.RegionObserver.preCheckAndDeleteAfterRowLock(ObserverContext<RegionCoprocessorEnvironment>, byte[], byte[], byte[], CompareOperator, ByteArrayComparable, Delete, boolean)
    since 2.4.0 and will be removed in 4.0.0. Use RegionObserver.preCheckAndMutateAfterRowLock(ObserverContext, CheckAndMutate,CheckAndMutateResult) instead.
    org.apache.hadoop.hbase.coprocessor.RegionObserver.preCheckAndDeleteAfterRowLock(ObserverContext<RegionCoprocessorEnvironment>, byte[], Filter, Delete, boolean)
    since 2.4.0 and will be removed in 4.0.0. Use RegionObserver.preCheckAndMutateAfterRowLock(ObserverContext, CheckAndMutate,CheckAndMutateResult) instead.
    org.apache.hadoop.hbase.coprocessor.RegionObserver.preCheckAndPut(ObserverContext<RegionCoprocessorEnvironment>, byte[], byte[], byte[], CompareOperator, ByteArrayComparable, Put, boolean)
    since 2.4.0 and will be removed in 4.0.0. Use RegionObserver.preCheckAndMutate(ObserverContext, CheckAndMutate, CheckAndMutateResult) instead.
    org.apache.hadoop.hbase.coprocessor.RegionObserver.preCheckAndPut(ObserverContext<RegionCoprocessorEnvironment>, byte[], Filter, Put, boolean)
    since 2.4.0 and will be removed in 4.0.0. Use RegionObserver.preCheckAndMutate(ObserverContext, CheckAndMutate, CheckAndMutateResult) instead.
    org.apache.hadoop.hbase.coprocessor.RegionObserver.preCheckAndPutAfterRowLock(ObserverContext<RegionCoprocessorEnvironment>, byte[], byte[], byte[], CompareOperator, ByteArrayComparable, Put, boolean)
    since 2.4.0 and will be removed in 4.0.0. Use RegionObserver.preCheckAndMutateAfterRowLock(ObserverContext, CheckAndMutate,CheckAndMutateResult) instead.
    org.apache.hadoop.hbase.coprocessor.RegionObserver.preCheckAndPutAfterRowLock(ObserverContext<RegionCoprocessorEnvironment>, byte[], Filter, Put, boolean)
    since 2.4.0 and will be removed in 4.0.0. Use RegionObserver.preCheckAndMutateAfterRowLock(ObserverContext, CheckAndMutate,CheckAndMutateResult) instead.
    org.apache.hadoop.hbase.coprocessor.RegionObserver.preDelete(ObserverContext<RegionCoprocessorEnvironment>, Delete, WALEdit, Durability)
    since 2.5.0 and will be removed in 4.0.0. Use RegionObserver.preDelete(ObserverContext, Delete, WALEdit) instead.
    org.apache.hadoop.hbase.coprocessor.RegionObserver.preIncrement(ObserverContext<RegionCoprocessorEnvironment>, Increment)
    since 2.5.0 and will be removed in 4.0.0. Use RegionObserver.preIncrement(ObserverContext, Increment, WALEdit) instead.
    org.apache.hadoop.hbase.coprocessor.RegionObserver.preIncrementAfterRowLock(ObserverContext<RegionCoprocessorEnvironment>, Increment)
    since 2.5.0 and will be removed in 4.0.0. Use RegionObserver.preBatchMutate(ObserverContext, MiniBatchOperationInProgress) instead.
    org.apache.hadoop.hbase.coprocessor.RegionObserver.prePrepareTimeStampForDeleteVersion(ObserverContext<RegionCoprocessorEnvironment>, Mutation, Cell, byte[], Get)
    Since hbase-2.0.0. No replacement. To be removed in hbase-3.0.0 and replaced with something that doesn't expose IntefaceAudience.Private classes.
    org.apache.hadoop.hbase.coprocessor.RegionObserver.prePut(ObserverContext<RegionCoprocessorEnvironment>, Put, WALEdit, Durability)
    since 2.5.0 and will be removed in 4.0.0. Use RegionObserver.prePut(ObserverContext, Put, WALEdit) instead.
    org.apache.hadoop.hbase.coprocessor.RegionObserver.preStoreFileReaderOpen(ObserverContext<RegionCoprocessorEnvironment>, FileSystem, Path, FSDataInputStreamWrapper, long, CacheConfig, Reference, StoreFileReader)
    For Phoenix only, StoreFileReader is not a stable interface.
    org.apache.hadoop.hbase.coprocessor.RegionServerObserver.postReplicateLogEntries(ObserverContext<RegionServerCoprocessorEnvironment>)
    As of release 2.0.0 with out any replacement. This is maintained for internal usage by AccessController. Do not use these hooks in custom co-processors.
    org.apache.hadoop.hbase.coprocessor.RegionServerObserver.preReplicateLogEntries(ObserverContext<RegionServerCoprocessorEnvironment>)
    As of release 2.0.0 with out any replacement. This is maintained for internal usage by AccessController. Do not use these hooks in custom co-processors.
    org.apache.hadoop.hbase.coprocessor.WALObserver.postWALWrite(ObserverContext<? extends WALCoprocessorEnvironment>, RegionInfo, WALKey, WALEdit)
    Since hbase-2.0.0. To be replaced with an alternative that does not expose InterfaceAudience classes such as WALKey and WALEdit. Will be removed in hbase-3.0.0.
    org.apache.hadoop.hbase.coprocessor.WALObserver.preWALWrite(ObserverContext<? extends WALCoprocessorEnvironment>, RegionInfo, WALKey, WALEdit)
    Since hbase-2.0.0. To be replaced with an alternative that does not expose InterfaceAudience classes such as WALKey and WALEdit. Will be removed in hbase-3.0.0.
    org.apache.hadoop.hbase.filter.ColumnCountGetFilter.filterKeyValue(Cell)
    org.apache.hadoop.hbase.filter.ColumnPaginationFilter.filterKeyValue(Cell)
    org.apache.hadoop.hbase.filter.ColumnPrefixFilter.filterKeyValue(Cell)
    org.apache.hadoop.hbase.filter.ColumnRangeFilter.filterKeyValue(Cell)
    org.apache.hadoop.hbase.filter.CompareFilter.compareFamily(CompareFilter.CompareOp, ByteArrayComparable, Cell)
    Since 2.0.0. Will be removed in 3.0.0. Use CompareFilter.compareFamily(CompareOperator, ByteArrayComparable, Cell)
    org.apache.hadoop.hbase.filter.CompareFilter.compareQualifier(CompareFilter.CompareOp, ByteArrayComparable, Cell)
    Since 2.0.0. Will be removed in 3.0.0. Use CompareFilter.compareQualifier(CompareOperator, ByteArrayComparable, Cell)
    org.apache.hadoop.hbase.filter.CompareFilter.compareRow(CompareFilter.CompareOp, ByteArrayComparable, Cell)
    Since 2.0.0. Will be removed in 3.0.0. Use CompareFilter.compareRow(CompareOperator, ByteArrayComparable, Cell)
    org.apache.hadoop.hbase.filter.CompareFilter.compareValue(CompareFilter.CompareOp, ByteArrayComparable, Cell)
    Since 2.0.0. Will be removed in 3.0.0. Use CompareFilter.compareValue(CompareOperator, ByteArrayComparable, Cell)
    org.apache.hadoop.hbase.filter.CompareFilter.getOperator()
    since 2.0.0. Will be removed in 3.0.0. Use CompareFilter.getCompareOperator() instead.
    org.apache.hadoop.hbase.filter.DependentColumnFilter.filterKeyValue(Cell)
    org.apache.hadoop.hbase.filter.FamilyFilter.filterKeyValue(Cell)
    org.apache.hadoop.hbase.filter.Filter.filterKeyValue(Cell)
    As of release 2.0.0, this will be removed in HBase 3.0.0. Instead use filterCell(Cell)
    org.apache.hadoop.hbase.filter.Filter.filterRowKey(byte[], int, int)
    As of release 2.0.0, this will be removed in HBase 3.0.0. Instead use Filter.filterRowKey(Cell)
    org.apache.hadoop.hbase.filter.FilterBase.filterRowKey(byte[], int, int)
    As of release 2.0.0, this will be removed in HBase 3.0.0. Instead use FilterBase.filterRowKey(Cell)
    org.apache.hadoop.hbase.filter.FilterList.filterKeyValue(Cell)
    org.apache.hadoop.hbase.filter.FilterWrapper.filterKeyValue(Cell)
    org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter.filterKeyValue(Cell)
    org.apache.hadoop.hbase.filter.FirstKeyValueMatchingQualifiersFilter.filterKeyValue(Cell)
    org.apache.hadoop.hbase.filter.FuzzyRowFilter.filterKeyValue(Cell)
    org.apache.hadoop.hbase.filter.InclusiveStopFilter.filterKeyValue(Cell)
    org.apache.hadoop.hbase.filter.KeyOnlyFilter.filterKeyValue(Cell)
    org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter.filterKeyValue(Cell)
    org.apache.hadoop.hbase.filter.MultiRowRangeFilter.filterKeyValue(Cell)
    org.apache.hadoop.hbase.filter.PageFilter.filterKeyValue(Cell)
    org.apache.hadoop.hbase.filter.ParseFilter.createCompareOp(byte[])
    Since 2.0

    org.apache.hadoop.hbase.filter.PrefixFilter.filterKeyValue(Cell)
    org.apache.hadoop.hbase.filter.QualifierFilter.filterKeyValue(Cell)
    org.apache.hadoop.hbase.filter.RandomRowFilter.filterKeyValue(Cell)
    org.apache.hadoop.hbase.filter.RowFilter.filterKeyValue(Cell)
    org.apache.hadoop.hbase.filter.SingleColumnValueFilter.filterKeyValue(Cell)
    org.apache.hadoop.hbase.filter.SingleColumnValueFilter.getOperator()
    since 2.0.0. Will be removed in 3.0.0. Use SingleColumnValueFilter.getCompareOperator() instead.
    org.apache.hadoop.hbase.filter.SkipFilter.filterKeyValue(Cell)
    org.apache.hadoop.hbase.filter.TimestampsFilter.filterKeyValue(Cell)
    org.apache.hadoop.hbase.filter.ValueFilter.filterKeyValue(Cell)
    org.apache.hadoop.hbase.filter.WhileMatchFilter.filterKeyValue(Cell)
    org.apache.hadoop.hbase.HBaseConfiguration.getInt(Configuration, String, String, int)
    it will be removed in 3.0.0. Use Configuration.addDeprecation(String, String) instead.
    org.apache.hadoop.hbase.HColumnDescriptor.getCompactionCompression()
    As of release 2.0.0, this will be removed in HBase 3.0.0 (HBASE-13655). Use HColumnDescriptor.getCompactionCompressionType().
    org.apache.hadoop.hbase.HColumnDescriptor.getCompression()
    As of release 2.0.0, this will be removed in HBase 3.0.0 (HBASE-13655). Use HColumnDescriptor.getCompressionType().
    org.apache.hadoop.hbase.HColumnDescriptor.isLegalFamilyName(byte[])
    since 2.0.0 and will be removed in 3.0.0. Use ColumnFamilyDescriptorBuilder.isLegalColumnFamilyName(byte[]) instead.
    org.apache.hadoop.hbase.HColumnDescriptor.setCacheDataInL1(boolean)
    Since 2.0 and will be removed in 3.0 with out any replacement. Caching data in on heap Cache, when there are both on heap LRU Cache and Bucket Cache will no longer be supported from 2.0.
    org.apache.hadoop.hbase.HRegionInfo.areAdjacent(HRegionInfo, HRegionInfo)
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionInfo.areAdjacent(RegionInfo, RegionInfo).
    org.apache.hadoop.hbase.HRegionInfo.convert(HRegionInfo)
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use toRegionInfo(org.apache.hadoop.hbase.client.RegionInfo) in org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil.
    org.apache.hadoop.hbase.HRegionInfo.convert(HBaseProtos.RegionInfo)
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use toRegionInfo(HBaseProtos.RegionInfo) in org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil.
    org.apache.hadoop.hbase.HRegionInfo.createRegionName(TableName, byte[], byte[], boolean)
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionInfo.createRegionName(TableName, byte[], byte[], boolean).
    org.apache.hadoop.hbase.HRegionInfo.createRegionName(TableName, byte[], byte[], int, boolean)
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionInfo.createRegionName(TableName, byte[], byte[], int, boolean).
    org.apache.hadoop.hbase.HRegionInfo.createRegionName(TableName, byte[], long, boolean)
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionInfo.createRegionName(TableName, byte[], long, boolean).
    org.apache.hadoop.hbase.HRegionInfo.createRegionName(TableName, byte[], long, int, boolean)
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionInfo.createRegionName(TableName, byte[], long, int, boolean).
    org.apache.hadoop.hbase.HRegionInfo.createRegionName(TableName, byte[], String, boolean)
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionInfo.createRegionName(TableName, byte[], String, boolean).
    org.apache.hadoop.hbase.HRegionInfo.encodeRegionName(byte[])
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionInfo.encodeRegionName(byte[]).
    org.apache.hadoop.hbase.HRegionInfo.getComparator()
    Use Region#getCellComparator(). deprecated for hbase 2.0, remove for hbase 3.0
    org.apache.hadoop.hbase.HRegionInfo.getDescriptiveNameFromRegionStateForDisplay(RegionState, Configuration)
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionInfoDisplay#getDescriptiveNameFromRegionStateForDisplay(RegionState, Configuration) over in hbase-server module.
    org.apache.hadoop.hbase.HRegionInfo.getEndKeyForDisplay(HRegionInfo, Configuration)
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionInfoDisplay#getEndKeyForDisplay(RegionInfo, Configuration) over in hbase-server module.
    org.apache.hadoop.hbase.HRegionInfo.getRegionNameAsStringForDisplay(HRegionInfo, Configuration)
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionInfoDisplay#getRegionNameAsStringForDisplay(RegionInfo, Configuration) over in hbase-server module.
    org.apache.hadoop.hbase.HRegionInfo.getRegionNameForDisplay(HRegionInfo, Configuration)
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionInfoDisplay#getRegionNameForDisplay(RegionInfo, Configuration) over in hbase-server module.
    org.apache.hadoop.hbase.HRegionInfo.getShortNameToLog(List<HRegionInfo>)
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionInfo.getShortNameToLog(List))}.
    org.apache.hadoop.hbase.HRegionInfo.getShortNameToLog(HRegionInfo...)
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionInfo.getShortNameToLog(RegionInfo...).
    org.apache.hadoop.hbase.HRegionInfo.getStartKey(byte[])
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionInfo.getStartKey(byte[]).
    org.apache.hadoop.hbase.HRegionInfo.getStartKeyForDisplay(HRegionInfo, Configuration)
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionInfoDisplay#getStartKeyForDisplay(RegionInfo, Configuration) over in hbase-server module.
    org.apache.hadoop.hbase.HRegionInfo.getTable(byte[])
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionInfo.getTable(byte[]).
    org.apache.hadoop.hbase.HRegionInfo.isEncodedRegionName(byte[])
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionInfo.isEncodedRegionName(byte[]).
    org.apache.hadoop.hbase.HRegionInfo.parseDelimitedFrom(byte[], int, int)
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionInfo.parseDelimitedFrom(byte[], int, int).
    org.apache.hadoop.hbase.HRegionInfo.parseFrom(byte[])
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionInfo.parseFrom(byte[]).
    org.apache.hadoop.hbase.HRegionInfo.parseFrom(byte[], int, int)
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionInfo.parseFrom(byte[], int, int).
    org.apache.hadoop.hbase.HRegionInfo.parseFrom(DataInputStream)
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionInfo.parseFrom(DataInputStream).
    org.apache.hadoop.hbase.HRegionInfo.parseFromOrNull(byte[])
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionInfo.parseFromOrNull(byte[]).
    org.apache.hadoop.hbase.HRegionInfo.parseFromOrNull(byte[], int, int)
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionInfo.parseFromOrNull(byte[], int, int).
    org.apache.hadoop.hbase.HRegionInfo.parseRegionName(byte[])
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionInfo.parseRegionName(byte[]).
    org.apache.hadoop.hbase.HRegionInfo.prettyPrint(String)
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionInfo.prettyPrint(String).
    org.apache.hadoop.hbase.HRegionInfo.toByteArray()
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionInfo.toByteArray(RegionInfo).
    org.apache.hadoop.hbase.HRegionInfo.toDelimitedByteArray()
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionInfo.toDelimitedByteArray(RegionInfo).
    org.apache.hadoop.hbase.HRegionInfo.toDelimitedByteArray(HRegionInfo...)
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionInfo.toDelimitedByteArray(RegionInfo...).
    org.apache.hadoop.hbase.HRegionLocation.getRegionInfo()
    Since 2.0.0. Will remove in 3.0.0. Use HRegionLocation.getRegion()} instead.
    org.apache.hadoop.hbase.HTableDescriptor.getColumnFamilies()
    since 2.0.0 and will be removed in 3.0.0.
    org.apache.hadoop.hbase.HTableDescriptor.getFamilies()
    since 2.0.0 and will be removed in 3.0.0. Use HTableDescriptor.getColumnFamilies() instead.
    org.apache.hadoop.hbase.HTableDescriptor.getFamiliesKeys()
    As of release 2.0.0, this will be removed in HBase 3.0.0 (HBASE-18008). Use HTableDescriptor.getColumnFamilyNames().
    org.apache.hadoop.hbase.HTableDescriptor.getFamily(byte[])
    since 2.0.0 and will be removed in 3.0.0. Use HTableDescriptor.getColumnFamily(byte[]) instead.
    org.apache.hadoop.hbase.HTableDescriptor.getOwnerString()
    since 0.94.1
    org.apache.hadoop.hbase.HTableDescriptor.hasRegionMemstoreReplication()
    As of release 2.0.0, this will be removed in HBase 3.0.0. Use HTableDescriptor.hasRegionMemStoreReplication() instead
    org.apache.hadoop.hbase.HTableDescriptor.setOwner(User)
    since 0.94.1
    org.apache.hadoop.hbase.HTableDescriptor.setOwnerString(String)
    since 0.94.1
    org.apache.hadoop.hbase.HTableDescriptor.setRegionMemstoreReplication(boolean)
    As of release 2.0.0, this will be removed in HBase 3.0.0. Use HTableDescriptor.setRegionMemStoreReplication(boolean) instead
    org.apache.hadoop.hbase.http.HttpServer.Builder.setBindAddress(String)
    Since 0.99.0. Use HttpServer.Builder.addEndpoint(URI) instead.
    org.apache.hadoop.hbase.http.HttpServer.Builder.setName(String)
    Since 0.99.0. Use HttpServer.Builder.setAppDir(String) instead.
    org.apache.hadoop.hbase.http.HttpServer.Builder.setPort(int)
    Since 0.99.0. Use HttpServer.Builder.addEndpoint(URI) instead.
    org.apache.hadoop.hbase.http.HttpServer.getPort()
    Since 0.99.0
    org.apache.hadoop.hbase.http.InfoServer.addServlet(String, String, Class<? extends HttpServlet>)
    Use InfoServer.addUnprivilegedServlet(String, String, Class) or InfoServer.addPrivilegedServlet(String, String, Class) instead of this method which does not state outwardly what kind of authz rules will be applied to this servlet.
    org.apache.hadoop.hbase.http.InfoServer.getPort()
    Since 0.99.0
    org.apache.hadoop.hbase.io.hfile.HFileScanner.getKeyString()
    Since hbase-2.0.0
    org.apache.hadoop.hbase.io.hfile.HFileScanner.getValueString()
    Since hbase-2.0.0
    org.apache.hadoop.hbase.io.ImmutableBytesWritable.getSize()
    since 0.98.5. Use ImmutableBytesWritable.getLength() instead
    org.apache.hadoop.hbase.io.Reference.readFields(DataInput)
    Writables are going away. Use the pb serialization methods instead. Remove in a release after 0.96 goes out. This is here only to migrate old Reference files written with Writables before 0.96.
    org.apache.hadoop.hbase.io.TimeRange.withinTimeRange(byte[], int)
    This is made @InterfaceAudience.Private in the 2.0 line and above and may be changed to private or removed in 3.0. Use TimeRange.withinTimeRange(long) instead
    org.apache.hadoop.hbase.ipc.RpcServerInterface.call(BlockingService, Descriptors.MethodDescriptor, Message, CellScanner, long, MonitoredRPCHandler)
    As of release 1.3, this will be removed in HBase 3.0
    org.apache.hadoop.hbase.ipc.RpcServerInterface.call(BlockingService, Descriptors.MethodDescriptor, Message, CellScanner, long, MonitoredRPCHandler, long, int)
    As of release 2.0, this will be removed in HBase 3.0
    org.apache.hadoop.hbase.KeyValue.KVComparator.getShortMidpointKey(byte[], byte[])
    Since 0.99.2;
    org.apache.hadoop.hbase.KeyValue.oswrite(KeyValue, OutputStream, boolean)
    As of release 2.0.0, this will be removed in HBase 3.0.0. Instead use KeyValue.write(OutputStream, boolean)
    org.apache.hadoop.hbase.KeyValueUtil.ensureKeyValue(Cell)
    without any replacement.
    org.apache.hadoop.hbase.KeyValueUtil.ensureKeyValues(List<Cell>)
    org.apache.hadoop.hbase.mapreduce.CellCreator.create(byte[], int, int, byte[], int, int, byte[], int, int, long, byte[], int, int, String)
    since 0.98.9
    org.apache.hadoop.hbase.mapreduce.RowCounter.createSubmittableJob(Configuration, String[])
    as of release 2.3.0. Will be removed on 4.0.0. Please use main method instead.
    org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil.addDependencyJars(Configuration, Class<?>...)
    since 1.3.0 and will be removed in 3.0.0. Use TableMapReduceUtil.addDependencyJars(Job) instead.
    org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil.initCredentialsForCluster(Job, String)
    Since 1.2.0 and will be removed in 3.0.0. Use TableMapReduceUtil.initCredentialsForCluster(Job, Configuration) instead.
    org.apache.hadoop.hbase.mapreduce.TableRecordReaderImpl.retrieveGetCounterWithStringsParams(TaskAttemptContext)
    since 2.4.0 and 2.3.2, will be removed in 4.0.0
    org.apache.hadoop.hbase.mapreduce.TableRecordReaderImpl.updateCounters(ScanMetrics, long, Method, TaskAttemptContext, long)
    since 2.4.0 and 2.3.2, will be removed in 4.0.0 Use TableRecordReaderImpl.updateCounters(ScanMetrics, long, TaskAttemptContext, long) instead.
    org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormat.TableSnapshotRegionSplit.getRegionInfo()
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use TableSnapshotInputFormat.TableSnapshotRegionSplit.getRegion()
    org.apache.hadoop.hbase.master.LoadBalancer.isMasterCanHostUserRegions(Configuration)
    since 2.4.0, will be removed in 3.0.0.
    org.apache.hadoop.hbase.master.LoadBalancer.isSystemTablesOnlyOnMaster(Configuration)
    since 2.4.0, will be removed in 3.0.0.
    org.apache.hadoop.hbase.master.LoadBalancer.isTablesOnMaster(Configuration)
    since 2.4.0, will be removed in 3.0.0.
    org.apache.hadoop.hbase.master.MasterWalManager.getFailedServersFromLogFolders()
    With proc-v2, we can record the crash server with procedure store, so do not need to scan the wal directory to find out the splitting wal directory any more. Leave it here only because RecoverMetaProcedure(which is also deprecated) uses it.
    org.apache.hadoop.hbase.master.TableStateManager.deleteZooKeeper(TableName)
    Since 2.0.0. To be removed in hbase-3.0.0.
    org.apache.hadoop.hbase.MetaTableAccessor.getRegion(Connection, byte[])
    use MetaTableAccessor.getRegionLocation(Connection, byte[]) instead
    org.apache.hadoop.hbase.net.Address.getHostname()
    Use Address.getHostName() instead
    org.apache.hadoop.hbase.RegionLoad.getCompleteSequenceId()
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionLoad.getCompletedSequenceId() instead.
    org.apache.hadoop.hbase.RegionLoad.getCurrentCompactedKVs()
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionLoad.getCompactedCellCount() instead.
    org.apache.hadoop.hbase.RegionLoad.getFilteredReadRequestsCount()
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionLoad.getFilteredReadRequestCount() instead.
    org.apache.hadoop.hbase.RegionLoad.getLastMajorCompactionTs()
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionLoad.getLastMajorCompactionTimestamp() instead.
    org.apache.hadoop.hbase.RegionLoad.getMemStoreSizeMB()
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionLoad.getMemStoreSize() instead.
    org.apache.hadoop.hbase.RegionLoad.getName()
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionLoad.getRegionName() instead.
    org.apache.hadoop.hbase.RegionLoad.getReadRequestsCount()
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionLoad.getReadRequestCount() instead.
    org.apache.hadoop.hbase.RegionLoad.getRequestsCount()
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionMetrics.getRequestCount() instead.
    org.apache.hadoop.hbase.RegionLoad.getRootIndexSizeKB()
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionLoad.getStoreFileRootLevelIndexSize() instead.
    org.apache.hadoop.hbase.RegionLoad.getStoreCompleteSequenceId()
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionLoad.getStoreSequenceId() instead.
    org.apache.hadoop.hbase.RegionLoad.getStorefileIndexSizeKB()
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionLoad.getStoreFileRootLevelIndexSize() instead.
    org.apache.hadoop.hbase.RegionLoad.getStorefileIndexSizeMB()
    As of release 2.0.0, this will be removed in HBase 3.0.0 ((HBASE-3935)). Use RegionLoad.getStoreFileRootLevelIndexSize() instead.
    org.apache.hadoop.hbase.RegionLoad.getStorefiles()
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionLoad.getStoreFileCount() instead.
    org.apache.hadoop.hbase.RegionLoad.getStorefileSizeMB()
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionLoad.getStoreFileSize() instead.
    org.apache.hadoop.hbase.RegionLoad.getStores()
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionLoad.getStoreCount() instead.
    org.apache.hadoop.hbase.RegionLoad.getStoreUncompressedSizeMB()
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionLoad.getUncompressedStoreFileSize() instead.
    org.apache.hadoop.hbase.RegionLoad.getTotalCompactingKVs()
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionLoad.getCompactingCellCount() instead.
    org.apache.hadoop.hbase.RegionLoad.getTotalStaticBloomSizeKB()
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionLoad.getBloomFilterSize() instead.
    org.apache.hadoop.hbase.RegionLoad.getTotalStaticIndexSizeKB()
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionLoad.getStoreFileUncompressedDataIndexSize() instead.
    org.apache.hadoop.hbase.RegionLoad.getWriteRequestsCount()
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionLoad.getWriteRequestCount() instead.
    org.apache.hadoop.hbase.regionserver.FifoRpcSchedulerFactory.create(Configuration, PriorityFunction)
    org.apache.hadoop.hbase.regionserver.HRegion.checkAndMutate(byte[], byte[], byte[], CompareOperator, ByteArrayComparable, TimeRange, Mutation)
    org.apache.hadoop.hbase.regionserver.HRegion.checkAndMutate(byte[], Filter, TimeRange, Mutation)
    org.apache.hadoop.hbase.regionserver.HRegion.checkAndRowMutate(byte[], byte[], byte[], CompareOperator, ByteArrayComparable, TimeRange, RowMutations)
    org.apache.hadoop.hbase.regionserver.HRegion.checkAndRowMutate(byte[], Filter, TimeRange, RowMutations)
    org.apache.hadoop.hbase.regionserver.HRegion.getRegionDir(Path, String)
    For tests only; to be removed.
    org.apache.hadoop.hbase.regionserver.HRegion.initialize()
    use HRegion.createHRegion() or HRegion.openHRegion()
    org.apache.hadoop.hbase.regionserver.Region.checkAndMutate(byte[], byte[], byte[], CompareOperator, ByteArrayComparable, Mutation)
    since 2.4.0 and will be removed in 4.0.0. Use Region.checkAndMutate(CheckAndMutate) instead.
    org.apache.hadoop.hbase.regionserver.Region.checkAndMutate(byte[], byte[], byte[], CompareOperator, ByteArrayComparable, TimeRange, Mutation)
    since 2.4.0 and will be removed in 4.0.0. Use Region.checkAndMutate(CheckAndMutate) instead.
    org.apache.hadoop.hbase.regionserver.Region.checkAndMutate(byte[], Filter, Mutation)
    since 2.4.0 and will be removed in 4.0.0. Use Region.checkAndMutate(CheckAndMutate) instead.
    org.apache.hadoop.hbase.regionserver.Region.checkAndMutate(byte[], Filter, TimeRange, Mutation)
    since 2.4.0 and will be removed in 4.0.0. Use Region.checkAndMutate(CheckAndMutate) instead.
    org.apache.hadoop.hbase.regionserver.Region.checkAndRowMutate(byte[], byte[], byte[], CompareOperator, ByteArrayComparable, RowMutations)
    since 2.4.0 and will be removed in 4.0.0. Use Region.checkAndMutate(CheckAndMutate) instead.
    org.apache.hadoop.hbase.regionserver.Region.checkAndRowMutate(byte[], byte[], byte[], CompareOperator, ByteArrayComparable, TimeRange, RowMutations)
    since 2.4.0 and will be removed in 4.0.0. Use Region.checkAndMutate(CheckAndMutate) instead.
    org.apache.hadoop.hbase.regionserver.Region.checkAndRowMutate(byte[], Filter, RowMutations)
    since 2.4.0 and will be removed in 4.0.0. Use Region.checkAndMutate(CheckAndMutate) instead.
    org.apache.hadoop.hbase.regionserver.Region.checkAndRowMutate(byte[], Filter, TimeRange, RowMutations)
    since 2.4.0 and will be removed in 4.0.0. Use Region.checkAndMutate(CheckAndMutate) instead.
    org.apache.hadoop.hbase.regionserver.Region.processRowsWithLocks(RowProcessor<?, ?>)
    As of release 2.0.0, this will be removed in HBase 3.0.0. For customization, use Coprocessors instead.
    org.apache.hadoop.hbase.regionserver.Region.processRowsWithLocks(RowProcessor<?, ?>, long, long)
    As of release 2.0.0, this will be removed in HBase 3.0.0. For customization, use Coprocessors instead.
    org.apache.hadoop.hbase.regionserver.Region.processRowsWithLocks(RowProcessor<?, ?>, long, long, long)
    As of release 2.0.0, this will be removed in HBase 3.0.0. For customization, use Coprocessors instead.
    org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost.postInstantiateDeleteTracker(DeleteTracker)
    Since 2.0 with out any replacement and will be removed in 3.0
    org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost.postWALRestore(RegionInfo, WALKey, WALEdit)
    Since hbase-2.0.0. No replacement. To be removed in hbase-3.0.0 and replaced with something that doesn't expose IntefaceAudience.Private classes.
    org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost.prePrepareTimeStampForDeleteVersion(Mutation, Cell, byte[], Get)
    In hbase-2.0.0. Will be removed in hbase-3.0.0. Added explicitly for a single Coprocessor for its needs only. Will be removed.
    org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost.preWALRestore(RegionInfo, WALKey, WALEdit)
    Since hbase-2.0.0. No replacement. To be removed in hbase-3.0.0 and replaced with something that doesn't expose IntefaceAudience.Private classes.
    org.apache.hadoop.hbase.regionserver.RegionServerServices.getFlushPressure()
    org.apache.hadoop.hbase.regionserver.RpcSchedulerFactory.create(Configuration, PriorityFunction)
    since 1.0.0.
    org.apache.hadoop.hbase.regionserver.SimpleRpcSchedulerFactory.create(Configuration, PriorityFunction)
    since 1.0.0.
    org.apache.hadoop.hbase.regionserver.StoreFile.getModificationTimeStamp()
    Since 2.0.0. Will be removed in 3.0.0.
    org.apache.hadoop.hbase.regionserver.StoreFileReader.getScanner(boolean, boolean)
    since 2.0.0 and will be removed in 3.0.0. Do not write further code which depends on this call. Instead use getStoreFileScanner() which uses the StoreFileScanner class/interface which is the preferred way to scan a store with higher level concepts.
    org.apache.hadoop.hbase.regionserver.StoreFileReader.getScanner(boolean, boolean, boolean)
    since 2.0.0 and will be removed in 3.0.0. Do not write further code which depends on this call. Instead use getStoreFileScanner() which uses the StoreFileScanner class/interface which is the preferred way to scan a store with higher level concepts. should we cache the blocks? use pread (for concurrent small readers) is scanner being used for compaction?
    org.apache.hadoop.hbase.replication.ReplicationLoadSink.getTimeStampsOfLastAppliedOp()
    Since hbase-2.0.0. Will be removed in 3.0.0.
    org.apache.hadoop.hbase.replication.ReplicationLoadSource.getTimeStampOfLastShippedOp()
    Since 2.0.0. Will be removed in 3.0.0.
    org.apache.hadoop.hbase.replication.ReplicationPeer.trackPeerConfigChanges(ReplicationPeerConfigListener)
    since 2.1.0 and will be removed in 4.0.0. Use ReplicationPeer.registerPeerConfigListener(ReplicationPeerConfigListener) instead.
    org.apache.hadoop.hbase.replication.ReplicationPeerConfig.setBandwidth(long)
    as release of 2.0.0, and it will be removed in 3.0.0. Use ReplicationPeerConfigBuilder.setBandwidth(long) instead.
    org.apache.hadoop.hbase.replication.ReplicationPeerConfig.setClusterKey(String)
    as release of 2.0.0, and it will be removed in 3.0.0. Use ReplicationPeerConfigBuilder.setClusterKey(String) instead.
    org.apache.hadoop.hbase.replication.ReplicationPeerConfig.setExcludeNamespaces(Set<String>)
    as release of 2.0.0, and it will be removed in 3.0.0. Use ReplicationPeerConfigBuilder.setExcludeNamespaces(Set) instead.
    org.apache.hadoop.hbase.replication.ReplicationPeerConfig.setExcludeTableCFsMap(Map<TableName, ? extends Collection<String>>)
    as release of 2.0.0, and it will be removed in 3.0.0. Use ReplicationPeerConfigBuilder.setExcludeTableCFsMap(Map) instead.
    org.apache.hadoop.hbase.replication.ReplicationPeerConfig.setNamespaces(Set<String>)
    as release of 2.0.0, and it will be removed in 3.0.0. Use ReplicationPeerConfigBuilder.setNamespaces(Set) instead.
    org.apache.hadoop.hbase.replication.ReplicationPeerConfig.setReplicateAllUserTables(boolean)
    as release of 2.0.0, and it will be removed in 3.0.0. Use ReplicationPeerConfigBuilder.setReplicateAllUserTables(boolean) instead.
    org.apache.hadoop.hbase.replication.ReplicationPeerConfig.setReplicationEndpointImpl(String)
    as release of 2.0.0, and it will be removed in 3.0.0. Use ReplicationPeerConfigBuilder.setReplicationEndpointImpl(String) instead.
    org.apache.hadoop.hbase.replication.ReplicationPeerConfig.setTableCFsMap(Map<TableName, ? extends Collection<String>>)
    as release of 2.0.0, and it will be removed in 3.0.0. Use ReplicationPeerConfigBuilder.setTableCFsMap(Map) instead.
    org.apache.hadoop.hbase.replication.ReplicationUtils.contains(ReplicationPeerConfig, TableName)
    Will be removed in HBase 3. Use ReplicationPeerConfig.needToReplicate(TableName) instead.
    org.apache.hadoop.hbase.security.SecurityInfo.getServerPrincipal()
    Since 2.6.0, will be removed in 4.0.0. Use SecurityInfo.getServerPrincipals() instead.
    org.apache.hadoop.hbase.ServerLoad.getCurrentCompactedKVs()
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use ServerLoad.getRegionMetrics() instead.
    org.apache.hadoop.hbase.ServerLoad.getFilteredReadRequestsCount()
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use ServerLoad.getRegionMetrics() instead.
    org.apache.hadoop.hbase.ServerLoad.getLoad()
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use ServerLoad.getNumberOfRegions() instead.
    org.apache.hadoop.hbase.ServerLoad.getMaxHeapMB()
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use ServerLoad.getMaxHeapSize() instead.
    org.apache.hadoop.hbase.ServerLoad.getMemstoreSizeInMB()
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use ServerLoad.getRegionMetrics() instead.
    org.apache.hadoop.hbase.ServerLoad.getMemStoreSizeMB()
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use ServerLoad.getRegionMetrics() instead.
    org.apache.hadoop.hbase.ServerLoad.getNumberOfRegions()
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use ServerLoad.getRegionMetrics() instead.
    org.apache.hadoop.hbase.ServerLoad.getNumberOfRequests()
    As of release 2.0.0, this will be removed in HBase 3.0.0. Use ServerLoad.getRequestCountPerSecond() instead.
    org.apache.hadoop.hbase.ServerLoad.getReadRequestsCount()
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use ServerLoad.getRegionMetrics() instead.
    org.apache.hadoop.hbase.ServerLoad.getRegionServerCoprocessors()
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use ServerLoad.getCoprocessorNames() instead.
    org.apache.hadoop.hbase.ServerLoad.getRegionsLoad()
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use ServerLoad.getRegionMetrics() instead.
    org.apache.hadoop.hbase.ServerLoad.getReportTime()
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use ServerLoad.getReportTimestamp() instead.
    org.apache.hadoop.hbase.ServerLoad.getRequestsPerSecond()
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use ServerLoad.getRequestCountPerSecond() instead.
    org.apache.hadoop.hbase.ServerLoad.getRootIndexSizeKB()
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use ServerLoad.getRegionMetrics() instead.
    org.apache.hadoop.hbase.ServerLoad.getRsCoprocessors()
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use ServerLoad.getCoprocessorNames() instead.
    org.apache.hadoop.hbase.ServerLoad.getStorefileIndexSizeInMB()
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use ServerLoad.getRegionMetrics() instead.
    org.apache.hadoop.hbase.ServerLoad.getStorefileIndexSizeKB()
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use ServerLoad.getRegionMetrics() instead.
    org.apache.hadoop.hbase.ServerLoad.getStorefiles()
    As of release 2.0.0, this will be removed in HBase 3.0.0. Use ServerLoad.getRegionMetrics() instead.
    org.apache.hadoop.hbase.ServerLoad.getStorefileSizeInMB()
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use ServerLoad.getRegionMetrics() instead.
    org.apache.hadoop.hbase.ServerLoad.getStorefileSizeMB()
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use ServerLoad.getRegionMetrics() instead.
    org.apache.hadoop.hbase.ServerLoad.getStores()
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use ServerLoad.getRegionMetrics() instead.
    org.apache.hadoop.hbase.ServerLoad.getStoreUncompressedSizeMB()
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use ServerLoad.getRegionMetrics() instead.
    org.apache.hadoop.hbase.ServerLoad.getTotalCompactingKVs()
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use ServerLoad.getRegionMetrics() instead.
    org.apache.hadoop.hbase.ServerLoad.getTotalNumberOfRequests()
    As of release 2.0.0, this will be removed in HBase 3.0.0. Use ServerLoad.getRequestCount() instead.
    org.apache.hadoop.hbase.ServerLoad.getTotalStaticBloomSizeKB()
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use ServerLoad.getRegionMetrics() instead.
    org.apache.hadoop.hbase.ServerLoad.getTotalStaticIndexSizeKB()
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use ServerLoad.getRegionMetrics() instead.
    org.apache.hadoop.hbase.ServerLoad.getUsedHeapMB()
    As of release 2.0.0, this will be removed in HBase 3.0.0. Use ServerLoad.getUsedHeapSize() instead.
    org.apache.hadoop.hbase.ServerLoad.getWriteRequestsCount()
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use ServerLoad.getRegionMetrics() instead.
    org.apache.hadoop.hbase.ServerLoad.hasMaxHeapMB()
    As of release 2.0.0, this will be removed in HBase 3.0.0 No flag in 2.0
    org.apache.hadoop.hbase.ServerLoad.hasNumberOfRequests()
    As of release 2.0.0, this will be removed in HBase 3.0.0 No flag in 2.0
    org.apache.hadoop.hbase.ServerLoad.hasTotalNumberOfRequests()
    As of release 2.0.0, this will be removed in HBase 3.0.0 No flag in 2.0
    org.apache.hadoop.hbase.ServerLoad.hasUsedHeapMB()
    As of release 2.0.0, this will be removed in HBase 3.0.0 No flag in 2.0
    org.apache.hadoop.hbase.ServerLoad.obtainServerLoadPB()
    DONT use this pb object since the byte array backed may be modified in rpc layer
    org.apache.hadoop.hbase.ServerName.getHostAndPort()
    Since 2.0. Use ServerName.getAddress() instead.
    org.apache.hadoop.hbase.ServerName.getServerName(String, long)
    Since 2.0. Use ServerName.valueOf(String, long) instead.
    org.apache.hadoop.hbase.ServerName.getServerNameLessStartCode(String)
    Since 2.0. Use ServerName.getAddress()
    org.apache.hadoop.hbase.ServerName.getServerStartcodeFromServerName(String)
    Since 2.0. Use instance of ServerName to pull out start code.
    org.apache.hadoop.hbase.ServerName.getStartcode()
    Since 2.5.0, will be removed in 4.0.0. Use ServerName.getStartCode() instead.
    org.apache.hadoop.hbase.ServerName.parseHostname(String)
    Since 2.0. Use ServerName.valueOf(String)
    org.apache.hadoop.hbase.ServerName.parsePort(String)
    Since 2.0. Use ServerName.valueOf(String)
    org.apache.hadoop.hbase.ServerName.parseStartcode(String)
    Since 2.0. Use ServerName.valueOf(String)
    org.apache.hadoop.hbase.util.Bytes.binarySearch(byte[][], byte[], int, int, RawComparator<?>)
    since 2.0.0 and will be removed in 3.0.0. Use Bytes.binarySearch(byte[][], byte[], int, int) instead.
    org.apache.hadoop.hbase.util.Bytes.binarySearch(byte[][], Cell, RawComparator<Cell>)
    since 2.0.0 and will be removed in 3.0.0. Use Bytes.binarySearch(Cell[], Cell, CellComparator) instead.
    org.apache.hadoop.hbase.util.Bytes.getSize()
    since 2.0.0 and will be removed in 3.0.0. Use Bytes.getLength() instead.
    org.apache.hadoop.hbase.util.Bytes.putIntUnsafe(byte[], int, int)
    As of release 2.0.0, this will be removed in HBase 3.0.0.
    org.apache.hadoop.hbase.util.Bytes.putLongUnsafe(byte[], int, long)
    As of release 2.0.0, this will be removed in HBase 3.0.0.
    org.apache.hadoop.hbase.util.Bytes.putShortUnsafe(byte[], int, short)
    As of release 2.0.0, this will be removed in HBase 3.0.0.
    org.apache.hadoop.hbase.util.Bytes.readVLong(byte[], int)
    since 0.98.12. Use Bytes.readAsVLong(byte[],int) instead.
    org.apache.hadoop.hbase.util.Bytes.toByteString()
    As of release 2.0.0, this will be removed in HBase 3.0.0.
    org.apache.hadoop.hbase.util.Bytes.toIntUnsafe(byte[], int)
    As of release 2.0.0, this will be removed in HBase 3.0.0.
    org.apache.hadoop.hbase.util.Bytes.toLongUnsafe(byte[], int)
    As of release 2.0.0, this will be removed in HBase 3.0.0.
    org.apache.hadoop.hbase.util.Bytes.toShortUnsafe(byte[], int)
    As of release 2.0.0, this will be removed in HBase 3.0.0.
    org.apache.hadoop.hbase.util.CommonFSUtils.getWrongWALRegionDir(Configuration, TableName, String)
    For compatibility, will be removed in 4.0.0.
    org.apache.hadoop.hbase.util.FSUtils.getTableStoreFilePathMap(Map<String, Path>, FileSystem, Path, TableName, PathFilter, ExecutorService, HbckErrorReporter)
    Since 2.3.0. For removal in hbase4. Use ProgressReporter override instead.
    org.apache.hadoop.hbase.util.FSUtils.getTableStoreFilePathMap(FileSystem, Path, PathFilter, ExecutorService, HbckErrorReporter)
    Since 2.3.0. Will be removed in hbase4. Used FSUtils.getTableStoreFilePathMap(FileSystem, Path, PathFilter, ExecutorService, ProgressReporter)
    org.apache.hadoop.hbase.util.ZKDataMigrator.queryForTableStates(ZKWatcher)
    Since 2.0.0. To be removed in hbase-3.0.0.
    org.apache.hadoop.hbase.wal.WAL.Entry.setCompressionContext(CompressionContext)
    deparcated since hbase 2.1.0
    org.apache.hadoop.hbase.wal.WAL.getEarliestMemStoreSeqNum(byte[])
    Since version 1.2.0. Removing because not used and exposes subtle internal workings. Use WAL.getEarliestMemStoreSeqNum(byte[], byte[])
    org.apache.hadoop.hbase.wal.WALEdit.isMetaEditFamily(byte[])
    Since 2.3.0. Do not expose. Make protected.
    org.apache.hadoop.hbase.wal.WALKeyImpl.getLogSeqNum()
    Use WALKeyImpl.getSequenceId()
    org.apache.hadoop.hbase.wal.WALKeyImpl.setCompressionContext(CompressionContext)
    deparcated since hbase 2.1.0
    org.apache.hadoop.hbase.wal.WALSplitUtil.getMaxRegionSequenceId(Configuration, RegionInfo, IOExceptionSupplier<FileSystem>, IOExceptionSupplier<FileSystem>)
    Only for compatibility, will be removed in 4.0.0.
    org.apache.hadoop.hbase.zookeeper.ZKUtil.getChildDataAndWatchForNewChildren(ZKWatcher, String)
    Unused
    org.apache.hadoop.hbase.zookeeper.ZKUtil.getChildDataAndWatchForNewChildren(ZKWatcher, String, boolean)
    Unused
    org.apache.hadoop.hbase.zookeeper.ZKUtil.updateExistingNodeData(ZKWatcher, String, byte[], int)
    Unused
  • Deprecated Constructors
    Constructor
    Description
    org.apache.hadoop.hbase.client.Scan(byte[])
    since 2.0.0 and will be removed in 3.0.0. Use new Scan().withStartRow(startRow) instead.
    org.apache.hadoop.hbase.client.Scan(byte[], byte[])
    since 2.0.0 and will be removed in 3.0.0. Use new Scan().withStartRow(startRow).withStopRow(stopRow) instead.
    org.apache.hadoop.hbase.client.Scan(byte[], Filter)
    since 2.0.0 and will be removed in 3.0.0. Use new Scan().withStartRow(startRow).setFilter(filter) instead.
    org.apache.hadoop.hbase.client.SnapshotDescription(String, String)
    since 2.0.0 and will be removed in 3.0.0. Use the version with the TableName instance instead.
    org.apache.hadoop.hbase.client.SnapshotDescription(String, String, SnapshotType)
    since 2.0.0 and will be removed in 3.0.0. Use the version with the TableName instance instead.
    org.apache.hadoop.hbase.client.SnapshotDescription(String, String, SnapshotType, String)
    since 2.0.0 and will be removed in 3.0.0. Use the version with the TableName instance instead.
    org.apache.hadoop.hbase.client.SnapshotDescription(String, String, SnapshotType, String, long, int)
    since 2.0.0 and will be removed in 3.0.0. Use the version with the TableName instance instead.
    org.apache.hadoop.hbase.client.SnapshotDescription(String, TableName, SnapshotType, String, long, int)
    since 2.3.0 and will be removed in 4.0.0. Use SnapshotDescription(String, TableName, SnapshotType, String, long, int, Map)
    org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor(TableName, TableDescriptor)
    org.apache.hadoop.hbase.ClusterStatus(String, String, Map<ServerName, ServerLoad>, Collection<ServerName>, ServerName, Collection<ServerName>, List<RegionState>, String[], Boolean, int)
    As of release 2.0.0, this will be removed in HBase 3.0.0
    org.apache.hadoop.hbase.filter.CompareFilter(CompareFilter.CompareOp, ByteArrayComparable)
    Since 2.0.0. Will be removed in 3.0.0. Use other constructor.
    org.apache.hadoop.hbase.filter.DependentColumnFilter(byte[], byte[], boolean, CompareFilter.CompareOp, ByteArrayComparable)
    Since 2.0.0. Will be removed in 3.0.0. Use DependentColumnFilter(byte[], byte[], boolean, CompareOperator, ByteArrayComparable) instead.
    org.apache.hadoop.hbase.filter.FamilyFilter(CompareFilter.CompareOp, ByteArrayComparable)
    Since 2.0.0. Will be removed in 3.0.0. Use FamilyFilter(CompareOperator, ByteArrayComparable)
    org.apache.hadoop.hbase.filter.QualifierFilter(CompareFilter.CompareOp, ByteArrayComparable)
    Since 2.0.0. Will be removed in 3.0.0. Use QualifierFilter(CompareOperator, ByteArrayComparable) instead.
    org.apache.hadoop.hbase.filter.RowFilter(CompareFilter.CompareOp, ByteArrayComparable)
    Since 2.0.0. Will remove in 3.0.0. Use RowFilter(CompareOperator, ByteArrayComparable)} instead.
    org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter(byte[], byte[], CompareFilter.CompareOp, byte[])
    org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter(byte[], byte[], CompareFilter.CompareOp, ByteArrayComparable)
    Since 2.0.0. Will be removed in 3.0.0. Use SingleColumnValueExcludeFilter(byte[], byte[], CompareOperator, ByteArrayComparable)
    org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter(byte[], byte[], CompareFilter.CompareOp, ByteArrayComparable, boolean, boolean)
    Since 2.0.0. Will be removed in 3.0.0. Use SingleColumnValueExcludeFilter(byte[], byte[], CompareOperator, ByteArrayComparable, boolean, boolean)
    org.apache.hadoop.hbase.filter.SingleColumnValueFilter(byte[], byte[], CompareFilter.CompareOp, byte[])
    Since 2.0.0. Will be removed in 3.0.0. Use SingleColumnValueFilter(byte[], byte[], CompareOperator, byte[]) instead.
    org.apache.hadoop.hbase.filter.SingleColumnValueFilter(byte[], byte[], CompareFilter.CompareOp, ByteArrayComparable)
    Since 2.0.0. Will be removed in 3.0.0. Use SingleColumnValueFilter(byte[], byte[], CompareOperator, ByteArrayComparable) instead.
    org.apache.hadoop.hbase.filter.SingleColumnValueFilter(byte[], byte[], CompareFilter.CompareOp, ByteArrayComparable, boolean, boolean)
    Since 2.0.0. Will be removed in 3.0.0. Use SingleColumnValueFilter(byte[], byte[], CompareOperator, ByteArrayComparable, boolean, boolean) instead.
    org.apache.hadoop.hbase.filter.ValueFilter(CompareFilter.CompareOp, ByteArrayComparable)
    Since 2.0.0. Will be removed in 3.0.0. Use ValueFilter(CompareOperator, ByteArrayComparable)
    org.apache.hadoop.hbase.HBaseConfiguration()
    since 0.90.0. Please use HBaseConfiguration.create() instead.
    org.apache.hadoop.hbase.HBaseConfiguration(Configuration)
    since 0.90.0. Please use HBaseConfiguration.create(Configuration) instead.
    org.apache.hadoop.hbase.HColumnDescriptor(byte[])
    As of release 2.0.0, this will be removed in HBase 3.0.0 (HBASE-18433). Use ColumnFamilyDescriptorBuilder.of(byte[]).
    org.apache.hadoop.hbase.HColumnDescriptor(String)
    As of release 2.0.0, this will be removed in HBase 3.0.0 (HBASE-18433). Use ColumnFamilyDescriptorBuilder.of(String).
    org.apache.hadoop.hbase.HColumnDescriptor(HColumnDescriptor)
    As of release 2.0.0, this will be removed in HBase 3.0.0 (HBASE-18433). Use ColumnFamilyDescriptorBuilder.copy(ColumnFamilyDescriptor).
    org.apache.hadoop.hbase.http.HttpServer(String, String, int, boolean)
    Since 0.99.0
    org.apache.hadoop.hbase.http.HttpServer(String, String, int, boolean, Configuration)
    Since 0.99.0
    org.apache.hadoop.hbase.http.HttpServer(String, String, int, boolean, Configuration, String[])
    Since 0.99.0
    org.apache.hadoop.hbase.http.HttpServer(String, String, int, boolean, Configuration, AccessControlList)
    Since 0.99.0
    org.apache.hadoop.hbase.http.HttpServer(String, String, int, boolean, Configuration, AccessControlList, String[])
    Since 0.99.0
    org.apache.hadoop.hbase.io.Reference()
    need by pb serialization
    org.apache.hadoop.hbase.io.TimeRange()
    This is made @InterfaceAudience.Private in the 2.0 line and above and may be changed to private or removed in 3.0.
    org.apache.hadoop.hbase.io.TimeRange(byte[])
    This is made @InterfaceAudience.Private in the 2.0 line and above and may be changed to private or removed in 3.0.
    org.apache.hadoop.hbase.io.TimeRange(byte[], byte[])
    This is made @InterfaceAudience.Private in the 2.0 line and above and may be changed to private or removed in 3.0.
    org.apache.hadoop.hbase.io.TimeRange(long)
    This is made @InterfaceAudience.Private in the 2.0 line and above and may be changed to private or removed in 3.0.
    org.apache.hadoop.hbase.io.TimeRange(long, long)
    This is made @InterfaceAudience.Private in the 2.0 line and above and may be changed to private or removed in 3.0.
    org.apache.hadoop.hbase.ipc.ServerTooBusyException(InetSocketAddress, long)
    org.apache.hadoop.hbase.mapred.TableOutputFormat.TableRecordWriter(BufferedMutator)
    since 2.0.0 and will be removed in 3.0.0. Please use #TableRecordWriter(JobConf) instead. This version does not clean up connections and will leak connections (removed in 2.0).
    org.apache.hadoop.hbase.regionserver.HRegion(Path, WAL, FileSystem, Configuration, RegionInfo, TableDescriptor, RegionServerServices)
    Use other constructors.
    org.apache.hadoop.hbase.replication.ReplicationPeerConfig()
    as release of 2.0.0, and it will be removed in 3.0.0. Use ReplicationPeerConfigBuilder to create new ReplicationPeerConfig.
    org.apache.hadoop.hbase.util.Bytes(ByteString)
    As of release 2.0.0, this will be removed in HBase 3.0.0.
    org.apache.hadoop.hbase.wal.WALEdit(boolean)
    since 2.0.1 and will be removed in 4.0.0. Use WALEdit(int, boolean) instead.
    org.apache.hadoop.hbase.wal.WALEdit(int)
    since 2.0.1 and will be removed in 4.0.0. Use WALEdit(int, boolean) instead.