All Differences
Removals
Additions
Changes
Bold is New, strike is deleted


A  B C D E F G H I K L M N O P R S T U V W Z TOP
abortCacheFlush (byte[])
AbstractHFileReader
AbstractHFileReader.BlockIndexNotLoadedException
AbstractHFileReader.NotSeekedException
AbstractHFileWriter
Action
  org.apache.hadoop.hbase.client
  Action (Row, int) constructor
actualErrorRate
  type  () in org.apache.hadoop.hbase.util.ByteBloomFilter
  type  (long, long, int) in org.apache.hadoop.hbase.util.ByteBloomFilter
add
  type  (byte[]) in org.apache.hadoop.hbase.util.BloomFilter
  type  (byte[], int, int) in org.apache.hadoop.hbase.util.BloomFilter
addBloomFilter (BloomFilterWriter)
addColumn
  type  (byte[], HColumnDescriptor) in org.apache.hadoop.hbase.master.MasterFileSystem
  type  (byte[], HColumnDescriptor) in org.apache.hadoop.hbase.util.MetaUtils
addCoprocessor
  type  (String) in org.apache.hadoop.hbase.HTableDescriptor
  type  (String, Path, int, Map<String, String>) in org.apache.hadoop.hbase.HTableDescriptor
addInlineBlockWriter (InlineBlockWriter)
addLease (Lease)
addRegionsToMeta (CatalogTracker, List<HRegionInfo>)
allocBloom ()
append
  type  (byte[], byte[]) in org.apache.hadoop.hbase.regionserver.StoreFile.Writer
  type  (HRegionInfo, byte[], WALEdit, long) in org.apache.hadoop.hbase.regionserver.wal.HLog
  type  (HRegionInfo, HLogKey, WALEdit) in org.apache.hadoop.hbase.regionserver.wal.HLog
  type  (HRegionInfo, WALEdit, long, boolean) in org.apache.hadoop.hbase.regionserver.wal.HLog
  type  (HRegionInfo, byte[], WALEdit, long, HTableDescriptor) in org.apache.hadoop.hbase.regionserver.wal.HLog
  type  (HRegionInfo, HLogKey, WALEdit, HTableDescriptor) in org.apache.hadoop.hbase.regionserver.wal.HLog
AssignmentManager
  org.apache.hadoop.hbase.master
  AssignmentManager (Server, ServerManager, CatalogTracker, ExecutorService) constructor
AssignmentManager.RegionState

B  A C D E F G H I K L M N O P R S T U V W Z TOP
BaseEndpointCoprocessor
BaseMasterObserver
BaseRegionObserver
BitComparator
BlockCache
blockLoads
BlockType
BloomFilter
BloomFilterBase
BloomFilterFactory
BloomFilterWriter
ByteBloomFilter
  org.apache.hadoop.hbase.util
  ByteBloomFilter (int, float, int, int) constructor
  ByteBloomFilter (ByteBuffer) constructor
  ByteBloomFilter (int, double, int, int) constructor
  ByteBloomFilter (DataInput) constructor
Bytes

C  A B D E F G H I K L M N O P R S T U V W Z TOP
CACHE_BLOCKS_ON_WRITE_KEY
cacheBlock
  type  (String, ByteBuffer) in org.apache.hadoop.hbase.io.hfile.BlockCache
  type  (String, ByteBuffer, boolean) in org.apache.hadoop.hbase.io.hfile.BlockCache
  type  (String, HeapSize) in org.apache.hadoop.hbase.io.hfile.BlockCache
  type  (String, HeapSize, boolean) in org.apache.hadoop.hbase.io.hfile.BlockCache
  type  (String, ByteBuffer) in org.apache.hadoop.hbase.io.hfile.LruBlockCache
  type  (String, ByteBuffer, boolean) in org.apache.hadoop.hbase.io.hfile.LruBlockCache
  type  (String, HeapSize) in org.apache.hadoop.hbase.io.hfile.LruBlockCache
  type  (String, HeapSize, boolean) in org.apache.hadoop.hbase.io.hfile.LruBlockCache
  type  (String, ByteBuffer) in org.apache.hadoop.hbase.io.hfile.SimpleBlockCache
  type  (String, ByteBuffer, boolean) in org.apache.hadoop.hbase.io.hfile.SimpleBlockCache
  type  (String, HeapSize) in org.apache.hadoop.hbase.io.hfile.SimpleBlockCache
  type  (String, HeapSize, boolean) in org.apache.hadoop.hbase.io.hfile.SimpleBlockCache
CachedBlock
  org.apache.hadoop.hbase.io.hfile
  CachedBlock (String, ByteBuffer, long) constructor
  CachedBlock (String, ByteBuffer, long, boolean) constructor
  CachedBlock (String, HeapSize, long) constructor
  CachedBlock (String, HeapSize, long, boolean) constructor
cacheHits
checkFormatVersion (int)
checkIfBaseNodeAvailable ()
checkSplit ()
close
  type  () in org.apache.hadoop.hbase.io.hfile.HFile.Reader
  type  () in org.apache.hadoop.hbase.io.hfile.HFile.Writer
ClosedRegionHandler
closeRegion (ServerName, HRegionInfo)
ColumnPaginationFilter
ColumnRangeFilter
compactBloom ()
compactStores ()
CompoundBloomFilter
CompoundBloomFilterBase
CompoundBloomFilterWriter
computeBitSize (long, double)
computeFoldableByteSize (long, int)
computeHDFSBlockDistribution (FileSystem, Path)
computeHDFSBlocksDistribution
  type  (Configuration, HTableDescriptor, String) in org.apache.hadoop.hbase.regionserver.HRegion
  type  (FileSystem, FileStatus, long, long) in org.apache.hadoop.hbase.util.FSUtils
computeMaxKeys (long, double, int)
connect
  type  (Configuration, Watcher) in org.apache.hadoop.hbase.zookeeper.ZKUtil
  type  (Configuration, String, Watcher) in org.apache.hadoop.hbase.zookeeper.ZKUtil
  type  (Configuration, String, Watcher, String) in org.apache.hadoop.hbase.zookeeper.ZKUtil
contains
  type  (byte[], ByteBuffer) in org.apache.hadoop.hbase.util.BloomFilter
  type  (byte[], int, int, byte[], int, int, Hash, int) in org.apache.hadoop.hbase.util.ByteBloomFilter
Coprocessor
  org.apache.hadoop.hbase
  Coprocessor
Coprocessor.Priority
Coprocessor.State
  org.apache.hadoop.hbase
  Coprocessor.State
CoprocessorEnvironment
  org.apache.hadoop.hbase
  CoprocessorEnvironment
CoprocessorHost
CoprocessorHost.Environment
  org.apache.hadoop.hbase.coprocessor
  CoprocessorHost.Environment (Coprocessor, int, int, Configuration) constructor
CORRUPT_DIR_NAME
CP_HTD_ATTR_KEY_PATTERN
CP_HTD_ATTR_VALUE_PARAM_KEY_PATTERN
CP_HTD_ATTR_VALUE_PARAM_PATTERN
CP_HTD_ATTR_VALUE_PARAM_VALUE_PATTERN
CP_HTD_ATTR_VALUE_PATTERN
createAndPrepare (CoprocessorEnvironment, ObserverContext<T>)
createAnother ()
createBloomKey (byte[], int, int, byte[], int, int)
createBySize (int, double, int, int)
createEnvironment
  type  (Class<?>, Coprocessor, int, int, Configuration) in org.apache.hadoop.hbase.coprocessor.CoprocessorHost
  type  (Class<?>, Coprocessor, int, int, Configuration) in org.apache.hadoop.hbase.master.MasterCoprocessorHost
  type  (Class<?>, Coprocessor, int, int, Configuration) in org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
  type  (Class<?>, Coprocessor, int, int, Configuration) in org.apache.hadoop.hbase.regionserver.wal.WALCoprocessorHost
createHRegion
  type  (HRegionInfo, Path, Configuration) in org.apache.hadoop.hbase.regionserver.HRegion
  type  (HRegionInfo, Path, Configuration, HTableDescriptor) in org.apache.hadoop.hbase.regionserver.HRegion
  type  (HRegionInfo, Path, Configuration, HTableDescriptor, HLog) in org.apache.hadoop.hbase.regionserver.HRegion
createReader
  type  (FileSystem, Path, BlockCache, boolean, boolean) in org.apache.hadoop.hbase.io.hfile.HFile
  type  (Path, FSDataInputStream, long, BlockCache, boolean, boolean) in org.apache.hadoop.hbase.io.hfile.HFile
createTableDescriptor
  type  (HTableDescriptor) in org.apache.hadoop.hbase.master.MasterFileSystem
  type  (FileSystem, Path, HTableDescriptor) in org.apache.hadoop.hbase.util.FSUtils
  type  (HTableDescriptor, Configuration) in org.apache.hadoop.hbase.util.FSUtils
createWriter
  type  (FileSystem, Path, int) in org.apache.hadoop.hbase.regionserver.StoreFile
  type  (FileSystem, Path, int, Algorithm, KVComparator, Configuration, BloomType, int, boolean) in org.apache.hadoop.hbase.regionserver.StoreFile
  type  (FileSystem, Path, int, Configuration) in org.apache.hadoop.hbase.regionserver.StoreFile
  type  (FileSystem, Path, int, Algorithm, KVComparator, Configuration, BloomType, long) in org.apache.hadoop.hbase.regionserver.StoreFile

D  A B C E F G H I K L M N O P R S T U V W Z TOP
Delayable
Delete
deleteColumn
  type  (byte[], byte[]) in org.apache.hadoop.hbase.master.MasterFileSystem
  type  (byte[], byte[]) in org.apache.hadoop.hbase.util.MetaUtils
deleteFamily (HRegionInfo, byte[])
deleteStaleConnection (HConnection)
deleteTableDescriptorIfExists (String, Configuration)
DeleteTableHandler
deleteTables
  type  (String) in org.apache.hadoop.hbase.client.HBaseAdmin
  type  (Pattern) in org.apache.hadoop.hbase.client.HBaseAdmin
DependentColumnFilter
DisableTableHandler
disableTables
  type  (String) in org.apache.hadoop.hbase.client.HBaseAdmin
  type  (Pattern) in org.apache.hadoop.hbase.client.HBaseAdmin
DoubleOutputStream
dropDependentColumn ()
DynamicByteBloomFilter

E  A B C D F G H I K L M N O P R S T U V W Z TOP
EnableTableHandler
enableTables
  type  (String) in org.apache.hadoop.hbase.client.HBaseAdmin
  type  (Pattern) in org.apache.hadoop.hbase.client.HBaseAdmin
endDelay (Object)
equals (byte[], int, int, byte[], int, int)
EVICT_BLOCKS_ON_CLOSE_KEY
evictBlocksByPrefix
  type  (String) in org.apache.hadoop.hbase.io.hfile.BlockCache
  type  (String) in org.apache.hadoop.hbase.io.hfile.LruBlockCache
  type  (String) in org.apache.hadoop.hbase.io.hfile.SimpleBlockCache

F  A B C D E G H I K L M N O P R S T U V W Z TOP
findCoprocessor (String)
findCoprocessorEnvironment (String)
fixDupeAssignment (HBaseAdmin, HRegionInfo, List<ServerName>)
FixedFileTrailer
fixUnassigned (HBaseAdmin, HRegionInfo)
FORMAT_VERSION_KEY
formatStats (BloomFilterBase)
FSHDFSUtils
FSMapRUtils
FSTableDescriptors
FSUtils
fullScanMetaAndPrint (CatalogTracker)
fullScanMetaAndPrintHRIM (CatalogTracker)

G  A B C D E F H I K L M N O P R S T U V W Z TOP
getBlock
  type  (String, boolean) in org.apache.hadoop.hbase.io.hfile.BlockCache
  type  (String, boolean) in org.apache.hadoop.hbase.io.hfile.LruBlockCache
  type  (String, boolean) in org.apache.hadoop.hbase.io.hfile.SimpleBlockCache
getBlockCacheKey (String, long)
getBloomFilterMetadata ()
getBuffer ()
getByteSize
  type  () in org.apache.hadoop.hbase.util.BloomFilter
  type  () in org.apache.hadoop.hbase.util.ByteBloomFilter
getCall ()
getColumnFamilyName ()
getComparator ()
getConfiguration ()
getCurrentCall
  type  () in org.apache.hadoop.hbase.ipc.HBaseServer
  type  () in org.apache.hadoop.hbase.ipc.RpcServer
getCurrentSize
  type  () in org.apache.hadoop.hbase.io.hfile.BlockCache
  type  () in org.apache.hadoop.hbase.io.hfile.SimpleBlockCache
getDataBlockIndexReader ()
getDataWriter ()
getDFSCOutputStream ()
getEntries
  type  () in org.apache.hadoop.hbase.io.hfile.HFile.Reader
  type  () in org.apache.hadoop.hbase.regionserver.StoreFile.Reader
getEnvironment
  type  () in org.apache.hadoop.hbase.coprocessor.BaseEndpointCoprocessor
  type  () in org.apache.hadoop.hbase.coprocessor.ObserverContext
getEvictedCount
  type  () in org.apache.hadoop.hbase.io.hfile.BlockCache
  type  () in org.apache.hadoop.hbase.io.hfile.SimpleBlockCache
getFamily ()
getFilterEntries
  type  () in org.apache.hadoop.hbase.io.hfile.HFile.Reader
  type  () in org.apache.hadoop.hbase.regionserver.StoreFile.Reader
getFormatVersion (Configuration)
getFreeSize
  type  () in org.apache.hadoop.hbase.io.hfile.BlockCache
  type  () in org.apache.hadoop.hbase.io.hfile.SimpleBlockCache
getHashCount ()
getHashType ()
getHDFSBlockDistribution ()
getHDFSBlocksDistribution ()
getHFileVersion ()
getHRegionInfo (Result)
getHRegionInfoForMigration
  type  (Result) in org.apache.hadoop.hbase.catalog.MetaEditor
  type  (byte[]) in org.apache.hadoop.hbase.util.Writables
getHTableDescriptor (Configuration, String)
getHTableDescriptors
  type  (List<String>) in org.apache.hadoop.hbase.client.HConnection
  type  () in org.apache.hadoop.hbase.ipc.HMasterInterface
  type  (List<String>) in org.apache.hadoop.hbase.ipc.HMasterInterface
  type  () in org.apache.hadoop.hbase.master.HMaster
  type  (List<String>) in org.apache.hadoop.hbase.master.HMaster
getInstance
  type  () in org.apache.hadoop.hbase.coprocessor.CoprocessorHost.Environment
  type  (FileSystem, Configuration) in org.apache.hadoop.hbase.util.FSUtils
getKeyCount
  type  () in org.apache.hadoop.hbase.util.BloomFilter
  type  () in org.apache.hadoop.hbase.util.ByteBloomFilter
getLimit ()
getMaxColumnInclusive ()
getMaxKeys
  type  () in org.apache.hadoop.hbase.util.BloomFilter
  type  () in org.apache.hadoop.hbase.util.ByteBloomFilter
getMetaBlock (String, boolean)
getMetaWriter ()
getMinColumnInclusive ()
getNodes ()
getOffset ()
getOnlineRegions
  type  () in org.apache.hadoop.hbase.ipc.HRegionInterface
  type  () in org.apache.hadoop.hbase.regionserver.HRegionServer
getOperator ()
getPriority ()
getQualifier ()
getReadTime ()
getReadTimeMs ()
getRecoverableZooKeeper ()
getRegionInfo (byte[])
getScanner
  type  (boolean, boolean, boolean) in org.apache.hadoop.hbase.io.hfile.HFile.Reader
  type  (Scan) in org.apache.hadoop.hbase.regionserver.HRegion
getTableDesc ()
getTableDescriptor
  type  (byte[]) in org.apache.hadoop.hbase.client.HBaseAdmin
  type  (FileSystem, Path, byte[]) in org.apache.hadoop.hbase.util.FSUtils
  type  (FileSystem, Path) in org.apache.hadoop.hbase.util.FSUtils
  type  (FileSystem, Path, String) in org.apache.hadoop.hbase.util.FSUtils
getTableDescriptors
  type  (List<String>) in org.apache.hadoop.hbase.client.HBaseAdmin
  type  () in org.apache.hadoop.hbase.master.HMaster
  type  () in org.apache.hadoop.hbase.master.MasterServices
getTableDirs (FileSystem, Path)
getTableInfoModtime (FileSystem, Path, String)
getTableName ()
getTableNameAsString ()
getTablePath
  type  (Path, byte[]) in org.apache.hadoop.hbase.util.FSUtils
  type  (Path, String) in org.apache.hadoop.hbase.util.FSUtils
getTaskAttemptContext (Job)
getTimestamps ()
getTotalBloomSize ()
getTotalBytes ()
getTotalUncompressedBytes ()
getTrailer ()
getTrailerInfo ()
getVersion (ZooKeeperWatcher, HRegionInfo)
getWebAppDir (String)
getWriterFactory (Configuration)
getWriterFSDataOutputStream ()
getWriteTime ()
getWriteTimeMs ()
getWriteToWAL ()
getZooKeeper ()

H  A B C D E F G I K L M N O P R S T U V W Z TOP
hasCoprocessor (String)
HBASE_NON_USER_TABLE_DIRS
HBaseAdmin
HBaseFsckRepair
HBaseServer
HConnection
HConnectionManager
HConstants
HDFSBlocksDistribution
HDFSBlocksDistribution.HostAndWeight
HDFSBlocksDistribution.HostAndWeight.WeightComparator
hdfsBlocksLocalityIndex
HFile
HFile.Reader
  org.apache.hadoop.hbase.io.hfile
  HFile.Reader (FileSystem, Path, BlockCache, boolean, boolean) constructor
  HFile.Reader (Path, FSDataInputStream, long, BlockCache, boolean, boolean) constructor
HFile.Writer
  org.apache.hadoop.hbase.io.hfile
  HFile.Writer (FSDataOutputStream, int, String, KeyComparator) constructor
  HFile.Writer (FSDataOutputStream, int, Algorithm, KeyComparator) constructor
  HFile.Writer (FileSystem, Path) constructor
  HFile.Writer (FileSystem, Path, int, String, KeyComparator) constructor
  HFile.Writer (FileSystem, Path, int, Algorithm, KeyComparator, BlockCache) constructor
HFile.WriterFactory
HFileBlock
HFileBlock.AbstractFSReader
HFileBlock.BasicReader
HFileBlock.BlockIterator
HFileBlock.BlockWritable
HFileBlock.FSReader
HFileBlock.FSReaderV1
HFileBlock.FSReaderV2
HFileBlock.Writer
HFileBlockIndex
HFileBlockIndex.BlockIndexReader
HFileBlockIndex.BlockIndexWriter
HFilePrettyPrinter
HFileReaderV1
HFileReaderV2
HFileWriterV1
HFileWriterV2
hflush ()
HLog
  org.apache.hadoop.hbase.regionserver.wal
  HLog (FileSystem, Path, Path, Configuration, List<WALObserver>, boolean, String) constructor
  HLog (FileSystem, Path, Path, Configuration, List<WALObserver>, String) constructor
  HLog (FileSystem, Path, Path, Configuration, List<WALActionsListener>, boolean, String) constructor
  HLog (FileSystem, Path, Path, Configuration, List<WALActionsListener>, String) constructor
HLogKey
HLogPrettyPrinter
HMaster
HMasterInterface
HRegion
  org.apache.hadoop.hbase.regionserver
  HRegion (Path, HLog, FileSystem, Configuration, HRegionInfo, RegionServerServices) constructor
  HRegion (Path, HLog, FileSystem, Configuration, HRegionInfo, HTableDescriptor, RegionServerServices) constructor
HRegionInfo
  org.apache.hadoop.hbase
  HRegionInfo (HTableDescriptor, byte[], byte[]) constructor
  HRegionInfo (HTableDescriptor, byte[], byte[], boolean) constructor
  HRegionInfo (HTableDescriptor, byte[], byte[], boolean, long) constructor
  HRegionInfo (byte[]) constructor
  HRegionInfo (byte[], byte[], byte[]) constructor
  HRegionInfo (byte[], byte[], byte[], boolean) constructor
  HRegionInfo (byte[], byte[], byte[], boolean, long) constructor
  HRegionInfo (HRegionInfo090x) constructor
HRegionInterface
HRegionServer
HServerLoad.RegionLoad
  org.apache.hadoop.hbase
  HServerLoad.RegionLoad (byte[], int, int, int, int, int, int, int) constructor
  HServerLoad.RegionLoad (byte[], int, int, int, int, int, int, int, int, int, int, int) constructor
HTable
HTableDescriptor
HTablePool
HTableUtil

I  A B C D E F G H K L M N O P R S T U V W Z TOP
idealMaxKeys (long, double)
IdLock
IdLock.Entry
impl
InfoServer
  org.apache.hadoop.hbase.util
  InfoServer (String, String, int, boolean, Configuration) constructor
initTableMapperJob
  type  (byte[], Scan, Class<TableMapper>, Class<? extends WritableComparable>, Class<? extends Writable>, Job, boolean, Class<? extends InputFormat>) in org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
  type  (String, Scan, Class<TableMapper>, Class<? extends WritableComparable>, Class<? extends Writable>, Job, boolean, Class<? extends InputFormat>) in org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
InlineBlockWriter
inMemory ()
InputSampler
isMetaHRIUpdated ()
isServerOnline (ServerName)

K  A B C D E F G H I L M N O P R S T U V W Z TOP
KeyValue

L  A B C D E F G H I K M N O P R S T U V W Z TOP
Leases
listTables
  type  (String) in org.apache.hadoop.hbase.client.HBaseAdmin
  type  (Pattern) in org.apache.hadoop.hbase.client.HBaseAdmin
load
  type  (Path, String, Priority) in org.apache.hadoop.hbase.coprocessor.CoprocessorHost
  type  (Class<?>, Priority) in org.apache.hadoop.hbase.coprocessor.CoprocessorHost
  type  (Path, String, int, Configuration) in org.apache.hadoop.hbase.coprocessor.CoprocessorHost
  type  (Class<?>, int, Configuration) in org.apache.hadoop.hbase.coprocessor.CoprocessorHost
LoadBalancer
loadInstance (Class<?>, int, Configuration)
LOG2_SQUARED
logVersion ()
LONG_BYTES
LruBlockCache

M  A B C D E F G H I K L N O P R S T U V W Z TOP
MasterCoprocessorEnvironment
MasterCoprocessorHost
MasterFileSystem
  org.apache.hadoop.hbase.master
  MasterFileSystem (Server, MasterServices, MasterMetrics) constructor
MasterObserver
MasterServices
MAX_FORMAT_VERSION
META_MIGRATION_QUALIFIER
MetaEditor
metaLoads
MetaReader
MetaServerShutdownHandler
MetaUtils
MIN_FORMAT_VERSION
modifyColumn (byte[], HColumnDescriptor)
ModifyTableHandler
MultipleColumnPrefixFilter

N  A B C D E F G H I K L M O P R S T U V W Z TOP
newHRegion (Path, HLog, FileSystem, Configuration, HRegionInfo, HTableDescriptor, RegionServerServices)

O  A B C D E F G H I K L M N P R S T U V W Z TOP
Objects
ObserverContext
OpenedRegionHandler
openHRegion
  type  (HRegionInfo, HLog, Configuration) in org.apache.hadoop.hbase.regionserver.HRegion
  type  (HRegionInfo, HLog, Configuration, RegionServerServices, CancelableProgressable) in org.apache.hadoop.hbase.regionserver.HRegion
  type  (Path, HRegionInfo, HTableDescriptor, HLog, Configuration) in org.apache.hadoop.hbase.regionserver.HRegion
  type  (Path, HRegionInfo, HTableDescriptor, HLog, Configuration, RegionServerServices, CancelableProgressable) in org.apache.hadoop.hbase.regionserver.HRegion
  type  (HRegionInfo, HTableDescriptor, HLog, Configuration) in org.apache.hadoop.hbase.regionserver.HRegion
  type  (HRegionInfo, HTableDescriptor, HLog, Configuration, RegionServerServices, CancelableProgressable) in org.apache.hadoop.hbase.regionserver.HRegion
OpenMetaHandler
  org.apache.hadoop.hbase.regionserver.handler
  OpenMetaHandler (Server, RegionServerServices, HRegionInfo, HTableDescriptor) constructor
openRegion
  type  (HRegionInfo) in org.apache.hadoop.hbase.ipc.HRegionInterface
  type  (HRegionInfo) in org.apache.hadoop.hbase.regionserver.HRegionServer
OpenRegionHandler
  org.apache.hadoop.hbase.regionserver.handler
  OpenRegionHandler (Server, RegionServerServices, HRegionInfo, HTableDescriptor) constructor
OpenRootHandler
  org.apache.hadoop.hbase.regionserver.handler
  OpenRootHandler (Server, RegionServerServices, HRegionInfo, HTableDescriptor) constructor
org.apache.hadoop.hbase
org.apache.hadoop.hbase.catalog
org.apache.hadoop.hbase.client
org.apache.hadoop.hbase.coprocessor
org.apache.hadoop.hbase.filter
org.apache.hadoop.hbase.io
org.apache.hadoop.hbase.io.hfile
org.apache.hadoop.hbase.ipc
org.apache.hadoop.hbase.mapreduce
org.apache.hadoop.hbase.mapreduce.hadoopbackport
org.apache.hadoop.hbase.master
org.apache.hadoop.hbase.master.handler
org.apache.hadoop.hbase.migration
org.apache.hadoop.hbase.regionserver
org.apache.hadoop.hbase.regionserver.handler
org.apache.hadoop.hbase.regionserver.metrics
org.apache.hadoop.hbase.regionserver.wal
org.apache.hadoop.hbase.replication.regionserver
org.apache.hadoop.hbase.util
org.apache.hadoop.hbase.zookeeper

P  A B C D E F G H I K L M N O R S T U V W Z TOP
PoolMap
  org.apache.hadoop.hbase.util
  PoolMap (PoolType) constructor
postScannerOpen
  type  (ObserverContext<RegionCoprocessorEnvironment>, Scan, RegionScanner) in org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
  type  (ObserverContext<RegionCoprocessorEnvironment>, Scan, RegionScanner) in org.apache.hadoop.hbase.coprocessor.RegionObserver
  type  (Scan, RegionScanner) in org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
postStartMaster
  type  (ObserverContext<MasterCoprocessorEnvironment>) in org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
  type  (ObserverContext<MasterCoprocessorEnvironment>) in org.apache.hadoop.hbase.coprocessor.MasterObserver
prepare (CoprocessorEnvironment)
preScannerOpen
  type  (ObserverContext<RegionCoprocessorEnvironment>, Scan, RegionScanner) in org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
  type  (ObserverContext<RegionCoprocessorEnvironment>, Scan, RegionScanner) in org.apache.hadoop.hbase.coprocessor.RegionObserver
  type  (Scan) in org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
processRpcResponse (Object, Writable, String, String)
putTable (HTableInterface)

R  A B C D E F G H I K L M N O P S T U V W Z TOP
readBlock (long, int, boolean, boolean, boolean)
readStringFixedSize (DataInput, int)
RecoverableZooKeeper
recoverFileLease (FileSystem, Path, Configuration)
RegionCoprocessorEnvironment
RegionCoprocessorHost
RegionObserver
RegionOpeningState
RegionScanner
RegionServerMetrics
RegionServerStoppedException
  org.apache.hadoop.hbase.regionserver
  RegionServerStoppedException (String) constructor
registerWALActionsListener (WALActionsListener)
Replication
RetryCounter
RetryCounterFactory
rollback (Server, RegionServerServices)
rootIndexSizeKB
RpcServer

S  A B C D E F G H I K L M N O P R T U V W Z TOP
sendRegionOpen (ServerName, HRegionInfo)
SequenceFileLogWriter
ServerManager
ServerNotRunningException
ServerNotRunningYetException
ServerShutdownHandler
setAutoFlush (boolean, boolean)
setClusterStatus (ClusterStatus)
setFakeLookupMode (boolean)
setMasterServices (MasterServices)
setTableDesc (HTableDescriptor)
setWriteToWAL (boolean)
shutdown (CoprocessorEnvironment)
SimpleBlockCache
size
  type  () in org.apache.hadoop.hbase.io.hfile.BlockCache
  type  () in org.apache.hadoop.hbase.io.hfile.SimpleBlockCache
SPLIT_LOGDIR_NAME
splitLog (List<ServerName>)
splitLogDistributed (List<Path>)
SplitLogManager
SplitRegionHandler
SplitTransaction
start
  type  (CoprocessorEnvironment) in org.apache.hadoop.hbase.coprocessor.BaseEndpointCoprocessor
  type  (CoprocessorEnvironment) in org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
  type  (CoprocessorEnvironment) in org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
startCacheFlush (byte[])
startDelay (Object)
STATS_RECORD_SEP
stop
  type  (CoprocessorEnvironment) in org.apache.hadoop.hbase.coprocessor.BaseEndpointCoprocessor
  type  (CoprocessorEnvironment) in org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
  type  (CoprocessorEnvironment) in org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
StoreFile
StoreFile.Reader
StoreFile.Writer
  org.apache.hadoop.hbase.regionserver
  StoreFile.Writer (FileSystem, Path, int, Algorithm, Configuration, KVComparator, BloomType, long) constructor
supportsAutoLoading
  type  () in org.apache.hadoop.hbase.util.BloomFilter
  type  () in org.apache.hadoop.hbase.util.ByteBloomFilter

T  A B C D E F G H I K L M N O P R S U V W Z TOP
TableAddFamilyHandler
TableDeleteFamilyHandler
TableDescriptors
TABLEINFO_NAME
TableMapReduceUtil
TableModifyFamilyHandler
TIMERANGE_KEY
TimestampsFilter
toString
  type  () in org.apache.hadoop.hbase.io.hfile.HFile.Reader
  type  () in org.apache.hadoop.hbase.io.hfile.HFile.Writer
  type  () in org.apache.hadoop.hbase.master.handler.ClosedRegionHandler
  type  () in org.apache.hadoop.hbase.master.handler.DeleteTableHandler
  type  () in org.apache.hadoop.hbase.master.handler.DisableTableHandler
  type  () in org.apache.hadoop.hbase.master.handler.EnableTableHandler
  type  () in org.apache.hadoop.hbase.master.handler.MetaServerShutdownHandler
  type  () in org.apache.hadoop.hbase.master.handler.ModifyTableHandler
  type  () in org.apache.hadoop.hbase.master.handler.OpenedRegionHandler
  type  () in org.apache.hadoop.hbase.master.handler.ServerShutdownHandler
  type  () in org.apache.hadoop.hbase.master.handler.SplitRegionHandler
  type  () in org.apache.hadoop.hbase.master.handler.TableAddFamilyHandler
  type  () in org.apache.hadoop.hbase.master.handler.TableDeleteFamilyHandler
  type  () in org.apache.hadoop.hbase.master.handler.TableModifyFamilyHandler
  type  () in org.apache.hadoop.hbase.util.ByteBloomFilter
toStringBinary (ByteBuffer)
toStringMap
  type  () in org.apache.hadoop.hbase.KeyValue
  type  () in org.apache.hadoop.hbase.regionserver.wal.HLogKey
totalStaticBloomSizeKB
totalStaticIndexSizeKB

U  A B C D E F G H I K L M N O P R S T V W Z TOP
unregisterWALActionsListener (WALActionsListener)
updateHTableDescriptor (FileSystem, Path, HTableDescriptor)
updateMetaWithNewRegionInfo (MasterServices)
updateRootWithMetaMigrationStatus
  type  (CatalogTracker) in org.apache.hadoop.hbase.catalog.MetaEditor
  type  (CatalogTracker, boolean) in org.apache.hadoop.hbase.catalog.MetaEditor
updateTimestamp (long)

V  A B C D E F G H I K L M N O P R S T U W Z TOP
VersionInfo
visitLogEntryBeforeWrite (HTableDescriptor, HLogKey, WALEdit)

W  A B C D E F G H I K L M N O P R S T U V Z TOP
WALActionsListener
WALCoprocessorEnvironment
WALCoprocessorHost
WALObserver
  org.apache.hadoop.hbase.coprocessor
  WALObserver
watchAndGetNewChildren (ZooKeeperWatcher, String)
WritableDelayed
Writables
writeStringFixedSize (DataOutput, String, int)

Z  A B C D E F G H I K L M N O P R S T U V W TOP
ZKAssign
ZKUtil
ZooKeeperListener
ZooKeeperNodeTracker
ZooKeeperWatcher
  org.apache.hadoop.hbase.zookeeper
  ZooKeeperWatcher (Configuration, String, Abortable, boolean) constructor
  ZooKeeperWatcher (Configuration, String, Abortable) constructor