Index

A B C D E F G H I J K L M N O P Q R S T U V W X Y Z 
All Classes and Interfaces|All Packages|Serialized Form

A

A - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for 'A'
ABNORMALLY_CLOSED - Enum constant in enum org.apache.hadoop.hbase.master.RegionState.State
 
abort(String) - Method in interface org.apache.hadoop.hbase.Abortable
It just calls another abort method and the Throwable parameter is null.
abort(String, Throwable) - Method in interface org.apache.hadoop.hbase.Abortable
Abort the server or client.
abort(String, Throwable) - Method in class org.apache.hadoop.hbase.backup.BackupHFileCleaner
 
abort(String, Throwable) - Method in interface org.apache.hadoop.hbase.client.Admin
 
abort(String, Throwable) - Method in class org.apache.hadoop.hbase.client.ConnectionImplementation
 
abort(String, Throwable) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
abort(String, Throwable) - Method in class org.apache.hadoop.hbase.client.HBaseHbck
 
abort(String, Throwable) - Method in class org.apache.hadoop.hbase.master.HMaster
 
abort(String, Throwable) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
Cause the server to exit without closing the regions it is serving, the log it is using and without notifying the master.
abort(String, Throwable) - Method in class org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint
 
abort(String, Throwable) - Method in class org.apache.hadoop.hbase.SharedConnection
 
abort(String, Throwable) - Method in class org.apache.hadoop.hbase.zookeeper.ZKWatcher
 
ABORT_ON_ERROR_KEY - Static variable in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
 
abortable - Variable in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
 
abortable - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
 
abortable - Variable in class org.apache.hadoop.hbase.wal.AbstractFSWALProvider
 
abortable - Variable in class org.apache.hadoop.hbase.wal.AbstractWALRoller
 
abortable - Variable in class org.apache.hadoop.hbase.zookeeper.ZKNodeTracker
Used to abort if a fatal error occurs
abortable - Variable in class org.apache.hadoop.hbase.zookeeper.ZKWatcher
 
org.apache.hadoop.hbase.Abortable - Interface in org.apache.hadoop.hbase
Interface to support the aborting of a given server or client.
abortCacheFlush(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
 
abortCacheFlush(byte[]) - Method in interface org.apache.hadoop.hbase.wal.WAL
Abort a cache flush.
ABORTED - Enum constant in enum org.apache.hadoop.hbase.ServerTask.State
 
abortProcedure(long, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
since 2.1.1 and will be removed in 4.0.0.
abortProcedure(long, boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Deprecated.
since 2.1.1 and will be removed in 4.0.0.
abortProcedure(long, boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
abortProcedure(long, boolean) - Method in class org.apache.hadoop.hbase.master.HMaster
 
abortProcedure(long, boolean) - Method in interface org.apache.hadoop.hbase.master.MasterServices
Abort a procedure.
abortProcedure(RpcController, MasterProtos.AbortProcedureRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
abortProcedure(RpcController, MasterProtos.AbortProcedureRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
 
abortProcedureAsync(long, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
since 2.1.1 and will be removed in 4.0.0.
abortProcedureAsync(long, boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
abortProcedureResult(MasterProtos.AbortProcedureRequest) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture
 
abortServer(E, Throwable) - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
 
abortServer(String, Throwable) - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
 
abortTask(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputCommitter
 
abortWriters() - Method in class org.apache.hadoop.hbase.regionserver.AbstractMultiFileWriter
Close all writers without throwing any exceptions.
ABOVE_HEAP_LOW_WATERMARK_COUNTER_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSource
 
ABOVE_HEAP_LOW_WATERMARK_COUNTER_NAME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSource
 
org.apache.hadoop.hbase.util.AbstractByteRange - Class in org.apache.hadoop.hbase.util
An abstract implementation of the ByteRange API
AbstractByteRange() - Constructor for class org.apache.hadoop.hbase.util.AbstractByteRange
 
org.apache.hadoop.hbase.client.AbstractClientScanner - Class in org.apache.hadoop.hbase.client
Helper class for custom client scanners.
AbstractClientScanner() - Constructor for class org.apache.hadoop.hbase.client.AbstractClientScanner
 
org.apache.hadoop.hbase.io.encoding.AbstractDataBlockEncoder - Class in org.apache.hadoop.hbase.io.encoding
 
AbstractDataBlockEncoder() - Constructor for class org.apache.hadoop.hbase.io.encoding.AbstractDataBlockEncoder
 
org.apache.hadoop.hbase.io.encoding.AbstractDataBlockEncoder.AbstractEncodedSeeker - Class in org.apache.hadoop.hbase.io.encoding
Decorates EncodedSeeker with a HFileBlockDecodingContext
AbstractEncodedSeeker(HFileBlockDecodingContext) - Constructor for class org.apache.hadoop.hbase.io.encoding.AbstractDataBlockEncoder.AbstractEncodedSeeker
 
org.apache.hadoop.hbase.util.AbstractFileStatusFilter - Class in org.apache.hadoop.hbase.util
Typical base class for file status filter.
AbstractFileStatusFilter() - Constructor for class org.apache.hadoop.hbase.util.AbstractFileStatusFilter
 
org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL<W extends org.apache.hadoop.hbase.wal.WALProvider.WriterBase> - Class in org.apache.hadoop.hbase.regionserver.wal
Implementation of WAL to go against FileSystem; i.e.
AbstractFSWAL(FileSystem, Path, String, String, Configuration, List<WALActionsListener>, boolean, String, String) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
 
AbstractFSWAL(FileSystem, Abortable, Path, String, String, Configuration, List<WALActionsListener>, boolean, String, String) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
 
org.apache.hadoop.hbase.wal.AbstractFSWALProvider<T extends org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL<?>> - Class in org.apache.hadoop.hbase.wal
Base class of a WAL Provider that returns a single thread safe WAL that writes to Hadoop FS.
AbstractFSWALProvider() - Constructor for class org.apache.hadoop.hbase.wal.AbstractFSWALProvider
 
org.apache.hadoop.hbase.wal.AbstractFSWALProvider.Initializer - Interface in org.apache.hadoop.hbase.wal
 
org.apache.hadoop.hbase.wal.AbstractFSWALProvider.WALStartTimeComparator - Class in org.apache.hadoop.hbase.wal
Comparator used to compare WAL files together based on their start time.
org.apache.hadoop.hbase.security.AbstractHBaseSaslRpcClient - Class in org.apache.hadoop.hbase.security
A utility class that encapsulates SASL logic for RPC client.
AbstractHBaseSaslRpcClient(Configuration, SaslClientAuthenticationProvider, Token<? extends TokenIdentifier>, InetAddress, String, boolean) - Constructor for class org.apache.hadoop.hbase.security.AbstractHBaseSaslRpcClient
Create a HBaseSaslRpcClient for an authentication method
AbstractHBaseSaslRpcClient(Configuration, SaslClientAuthenticationProvider, Token<? extends TokenIdentifier>, InetAddress, String, boolean, String) - Constructor for class org.apache.hadoop.hbase.security.AbstractHBaseSaslRpcClient
Create a HBaseSaslRpcClient for an authentication method
org.apache.hadoop.hbase.util.AbstractHBaseTool - Class in org.apache.hadoop.hbase.util
Common base class used for HBase command-line tools.
AbstractHBaseTool() - Constructor for class org.apache.hadoop.hbase.util.AbstractHBaseTool
 
org.apache.hadoop.hbase.util.AbstractHBaseTool.OptionsOrderComparator - Class in org.apache.hadoop.hbase.util
 
org.apache.hadoop.hbase.regionserver.AbstractMemStore - Class in org.apache.hadoop.hbase.regionserver
An abstract class, which implements the behaviour shared by all concrete memstore instances.
AbstractMemStore(Configuration, CellComparator, RegionServicesForStores) - Constructor for class org.apache.hadoop.hbase.regionserver.AbstractMemStore
 
org.apache.hadoop.hbase.regionserver.AbstractMultiFileWriter - Class in org.apache.hadoop.hbase.regionserver
Base class for cell sink that separates the provided cells into multiple files.
AbstractMultiFileWriter() - Constructor for class org.apache.hadoop.hbase.regionserver.AbstractMultiFileWriter
 
org.apache.hadoop.hbase.regionserver.AbstractMultiFileWriter.WriterFactory - Interface in org.apache.hadoop.hbase.regionserver
 
org.apache.hadoop.hbase.util.AbstractPositionedByteRange - Class in org.apache.hadoop.hbase.util
Extends the basic SimpleByteRange implementation with position support.
AbstractPositionedByteRange() - Constructor for class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
 
org.apache.hadoop.hbase.regionserver.wal.AbstractProtobufLogWriter - Class in org.apache.hadoop.hbase.regionserver.wal
Base class for Protobuf log writer.
AbstractProtobufLogWriter() - Constructor for class org.apache.hadoop.hbase.regionserver.wal.AbstractProtobufLogWriter
 
org.apache.hadoop.hbase.regionserver.wal.AbstractProtobufWALReader - Class in org.apache.hadoop.hbase.regionserver.wal
Base class for reading protobuf based wal reader
AbstractProtobufWALReader() - Constructor for class org.apache.hadoop.hbase.regionserver.wal.AbstractProtobufWALReader
 
org.apache.hadoop.hbase.ipc.AbstractRpcClient<T extends org.apache.hadoop.hbase.ipc.RpcConnection> - Class in org.apache.hadoop.hbase.ipc
Provides the basics for a RpcClient implementation like configuration and Logging.
AbstractRpcClient(Configuration, String, SocketAddress, MetricsConnection, Map<String, byte[]>) - Constructor for class org.apache.hadoop.hbase.ipc.AbstractRpcClient
Construct an IPC client for the cluster clusterId
org.apache.hadoop.hbase.ipc.AbstractRpcClient.BlockingRpcChannelImplementation - Class in org.apache.hadoop.hbase.ipc
Blocking rpc channel that goes via hbase rpc.
org.apache.hadoop.hbase.ipc.AbstractRpcClient.RpcChannelImplementation - Class in org.apache.hadoop.hbase.ipc
Async rpc channel that goes via hbase rpc.
org.apache.hadoop.hbase.hbtop.screen.AbstractScreenView - Class in org.apache.hadoop.hbase.hbtop.screen
An abstract class for ScreenView that has the common useful methods and the default implementations for the abstract methods.
AbstractScreenView(Screen, Terminal) - Constructor for class org.apache.hadoop.hbase.hbtop.screen.AbstractScreenView
 
org.apache.hadoop.hbase.quotas.policies.AbstractViolationPolicyEnforcement - Class in org.apache.hadoop.hbase.quotas.policies
Abstract implementation for SpaceViolationPolicyEnforcement.
AbstractViolationPolicyEnforcement() - Constructor for class org.apache.hadoop.hbase.quotas.policies.AbstractViolationPolicyEnforcement
 
org.apache.hadoop.hbase.wal.AbstractWALRoller<T extends org.apache.hadoop.hbase.Abortable> - Class in org.apache.hadoop.hbase.wal
Runs periodically to determine if the WAL should be rolled.
AbstractWALRoller(String, Configuration, T) - Constructor for class org.apache.hadoop.hbase.wal.AbstractWALRoller
 
org.apache.hadoop.hbase.wal.AbstractWALRoller.RollController - Class in org.apache.hadoop.hbase.wal
Independently control the roll of each wal.
accept(Class<?>) - Method in class org.apache.hadoop.hbase.mapreduce.CellSerialization
 
accept(Class<?>) - Method in class org.apache.hadoop.hbase.mapreduce.ExtendedCellSerialization
 
accept(Class<?>) - Method in class org.apache.hadoop.hbase.mapreduce.KeyValueSerialization
Deprecated.
 
accept(Class<?>) - Method in class org.apache.hadoop.hbase.mapreduce.MutationSerialization
 
accept(Class<?>) - Method in class org.apache.hadoop.hbase.mapreduce.ResultSerialization
 
accept(FileStatus) - Method in class org.apache.hadoop.hbase.util.AbstractFileStatusFilter
 
accept(FileStatus) - Method in interface org.apache.hadoop.hbase.util.FileStatusFilter
Tests whether or not the specified filestatus should be included in a filestatus list.
accept(Path) - Method in class org.apache.hadoop.hbase.util.AbstractFileStatusFilter
 
accept(Path) - Method in class org.apache.hadoop.hbase.util.FSUtils.HFileLinkFilter
 
accept(Path) - Method in class org.apache.hadoop.hbase.util.FSUtils.ReferenceAndLinkFileFilter
 
accept(Path, Boolean) - Method in class org.apache.hadoop.hbase.util.AbstractFileStatusFilter
Filters out a path.
accept(Path, Boolean) - Method in class org.apache.hadoop.hbase.util.FSUtils.BlackListDirFilter
 
accept(Path, Boolean) - Method in class org.apache.hadoop.hbase.util.FSUtils.FamilyDirFilter
 
accept(Path, Boolean) - Method in class org.apache.hadoop.hbase.util.FSUtils.HFileFilter
 
accept(Path, Boolean) - Method in class org.apache.hadoop.hbase.util.FSUtils.ReferenceFileFilter
 
accept(Path, Boolean) - Method in class org.apache.hadoop.hbase.util.FSUtils.RegionDirFilter
 
accept(Field, List<Field>, EnumMap<Field, Boolean>) - Method in interface org.apache.hadoop.hbase.hbtop.screen.field.FieldScreenPresenter.ResultListener
 
ACCEPT_POLICY_CONF_KEY - Static variable in class org.apache.hadoop.hbase.thrift.HThreadedSelectorServerArgs
The strategy for handling new accepted connections.
ACCEPT_QUEUE_SIZE_PER_THREAD_CONF_KEY - Static variable in class org.apache.hadoop.hbase.thrift.HThreadedSelectorServerArgs
Maximum number of accepted elements per selector
access(long) - Method in class org.apache.hadoop.hbase.io.hfile.LruCachedBlock
Block has been accessed.
access(long) - Method in class org.apache.hadoop.hbase.mob.CachedMobFile
 
org.apache.hadoop.hbase.security.AccessDeniedException - Exception in org.apache.hadoop.hbase.security
Exception thrown by access-related methods.
AccessDeniedException() - Constructor for exception org.apache.hadoop.hbase.security.AccessDeniedException
 
AccessDeniedException(Class<?>, String) - Constructor for exception org.apache.hadoop.hbase.security.AccessDeniedException
 
AccessDeniedException(String) - Constructor for exception org.apache.hadoop.hbase.security.AccessDeniedException
 
AccessDeniedException(Throwable) - Constructor for exception org.apache.hadoop.hbase.security.AccessDeniedException
 
ack(boolean) - Method in class org.apache.hadoop.hbase.util.RegionMover.RegionMoverBuilder
Set ack/noAck mode.
ACL_TAG_TYPE - Static variable in class org.apache.hadoop.hbase.TagType
 
acquire() - Method in class org.apache.hadoop.hbase.master.WorkerAssigner
 
acquireLock(K) - Method in class org.apache.hadoop.hbase.util.KeyLocker
Return a lock for the given key.
acquireLocks(Set<? extends K>) - Method in class org.apache.hadoop.hbase.util.KeyLocker
Acquire locks for a set of keys.
acquireSplitWALWorker(Procedure<?>) - Method in class org.apache.hadoop.hbase.master.SplitWALManager
Acquire a split WAL worker
org.apache.hadoop.hbase.client.Action - Class in org.apache.hadoop.hbase.client
A Get, Put, Increment, Append, or Delete associated with it's region.
Action(Action, int) - Constructor for class org.apache.hadoop.hbase.client.Action
Creates an action for a particular replica from original action.
Action(Row, int) - Constructor for class org.apache.hadoop.hbase.client.Action
 
Action(Row, int, int) - Constructor for class org.apache.hadoop.hbase.client.Action
 
ACTIVE - Enum constant in enum org.apache.hadoop.hbase.Coprocessor.State
 
ACTIVE - Enum constant in enum org.apache.hadoop.hbase.regionserver.wal.WALEventTrackerListener.WalState
 
ACTIVE_SCANNERS - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
ACTIVE_SCANNERS_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
ACTIVE_WORKER_COUNT_KEY - Static variable in interface org.apache.hadoop.hbase.thrift.MetricsThriftServerSource
 
org.apache.hadoop.hbase.master.ActiveMasterManager - Class in org.apache.hadoop.hbase.master
Handles everything on master-side related to master election.
activeOperations - Variable in class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareThroughputController
 
org.apache.hadoop.hbase.quotas.ActivePolicyEnforcement - Class in org.apache.hadoop.hbase.quotas
A class to ease dealing with tables that have and do not have violation policies being enforced.
ActivePolicyEnforcement(Map<TableName, SpaceViolationPolicyEnforcement>, Map<TableName, SpaceQuotaSnapshot>, RegionServerServices) - Constructor for class org.apache.hadoop.hbase.quotas.ActivePolicyEnforcement
 
ActivePolicyEnforcement(Map<TableName, SpaceViolationPolicyEnforcement>, Map<TableName, SpaceQuotaSnapshot>, RegionServerServices, SpaceViolationPolicyEnforcementFactory) - Constructor for class org.apache.hadoop.hbase.quotas.ActivePolicyEnforcement
 
actualErrorRate() - Method in class org.apache.hadoop.hbase.util.BloomFilterChunk
Computes the error rate for this Bloom filter, taking into account the actual number of hash functions and keys inserted.
actualErrorRate(long, long, int) - Static method in class org.apache.hadoop.hbase.util.BloomFilterUtil
Computes the actual error rate for the given number of elements, number of bits, and number of hash functions.
ADAPTIVE - Enum constant in enum org.apache.hadoop.hbase.MemoryCompactionPolicy
Adaptive compaction adapts to the workload.
ADAPTIVE_COMPACTION_THRESHOLD_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.AdaptiveMemStoreCompactionStrategy
 
ADAPTIVE_INITIAL_COMPACTION_PROBABILITY_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.AdaptiveMemStoreCompactionStrategy
 
org.apache.hadoop.hbase.ipc.AdaptiveLifoCoDelCallQueue - Class in org.apache.hadoop.hbase.ipc
Adaptive LIFO blocking queue utilizing CoDel algorithm to prevent queue overloading.
AdaptiveLifoCoDelCallQueue(int, int, int, double, LongAdder, LongAdder) - Constructor for class org.apache.hadoop.hbase.ipc.AdaptiveLifoCoDelCallQueue
 
org.apache.hadoop.hbase.regionserver.AdaptiveMemStoreCompactionStrategy - Class in org.apache.hadoop.hbase.regionserver
Adaptive is a heuristic that chooses whether to apply data compaction or not based on the level of redundancy in the data.
AdaptiveMemStoreCompactionStrategy(Configuration, String) - Constructor for class org.apache.hadoop.hbase.regionserver.AdaptiveMemStoreCompactionStrategy
 
add(byte[][]) - Static method in class org.apache.hadoop.hbase.util.Bytes
Concatenate byte arrays.
add(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
Concatenate byte arrays.
add(byte[], byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Append
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use Append.addColumn(byte[], byte[], byte[]) instead
add(byte[], byte[], byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
Concatenate byte arrays.
add(byte[], int, Object) - Method in class org.apache.hadoop.hbase.client.MultiResponse
Add the pair to the container, grouped by the regionName.
add(byte[], long, int) - Method in interface org.apache.hadoop.hbase.io.hfile.BlockIndexChunk
 
add(byte[], long, int, long) - Method in interface org.apache.hadoop.hbase.io.hfile.BlockIndexChunk
 
add(byte[], List<Action>) - Method in class org.apache.hadoop.hbase.client.MultiAction
Add an Action to this container based on it's regionName.
add(byte[], Action) - Method in class org.apache.hadoop.hbase.client.MultiAction
Add an Action to this container based on it's regionName.
add(int, E) - Method in class org.apache.hadoop.hbase.util.SortedList
 
add(long) - Method in class org.apache.hadoop.hbase.util.Counter
Deprecated.
 
add(long) - Method in interface org.apache.hadoop.metrics2.MetricHistogram
Add a single value to a histogram's stream of values.
add(E) - Method in class org.apache.hadoop.hbase.util.SortedList
 
add(Iterable<Cell>, MemStoreSizing) - Method in class org.apache.hadoop.hbase.regionserver.AbstractMemStore
 
add(Iterable<Cell>, MemStoreSizing) - Method in class org.apache.hadoop.hbase.regionserver.HStore
Adds the specified value to the memstore
add(Iterable<Cell>, MemStoreSizing) - Method in interface org.apache.hadoop.hbase.regionserver.MemStore
Write the updates
add(Runnable) - Method in class org.apache.hadoop.hbase.thrift.CallQueue
 
add(String) - Method in class org.apache.hadoop.hbase.rest.client.Cluster
Add a node to the cluster
add(String, int) - Method in class org.apache.hadoop.hbase.rest.client.Cluster
Add a node to the cluster
add(Collection<StoreFileInfo>) - Method in interface org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileTracker
Add new store files.
add(Iterator<T>) - Method in class org.apache.hadoop.hbase.util.ReservoirSample
 
add(List<? extends Mutation>) - Method in class org.apache.hadoop.hbase.client.RowMutations
Add a list of mutations
add(Map.Entry<byte[], List<Action>>) - Method in class org.apache.hadoop.hbase.client.DelayingRunner
 
add(Map<byte[], List<Cell>>) - Method in class org.apache.hadoop.hbase.wal.WALEdit
Append the given map of family->edits to a WALEdit data structure.
add(Stream<T>) - Method in class org.apache.hadoop.hbase.util.ReservoirSample
 
add(Configuration) - Method in class org.apache.hadoop.hbase.CompoundConfiguration
Add Hadoop Configuration object to config list.
add(Cell) - Method in class org.apache.hadoop.hbase.client.Append
Add column and value to this Append operation.
add(Cell) - Method in class org.apache.hadoop.hbase.client.Delete
Add an existing delete marker to this Delete object.
add(Cell) - Method in class org.apache.hadoop.hbase.client.Increment
Add the specified KeyValue to this operation.
add(Cell) - Method in class org.apache.hadoop.hbase.client.Put
Add the specified KeyValue to this Put operation.
add(Cell) - Method in class org.apache.hadoop.hbase.regionserver.CellSet
 
add(Cell) - Method in interface org.apache.hadoop.hbase.regionserver.querymatcher.DeleteTracker
Add the specified cell to the list of deletes to check against for this row operation.
add(Cell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.NewVersionBehaviorTracker
 
add(Cell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanDeleteTracker
Add the specified Cell to the list of deletes to check against for this row operation.
add(Cell) - Method in class org.apache.hadoop.hbase.util.BloomFilterChunk
 
add(Cell) - Method in class org.apache.hadoop.hbase.wal.WALEdit
 
add(Cell, boolean, MemStoreSizing, boolean) - Method in class org.apache.hadoop.hbase.regionserver.MutableSegment
Adds the given cell into the segment
add(Cell, byte[]) - Method in class org.apache.hadoop.hbase.wal.WALEdit
 
add(Cell, MemStoreSizing) - Method in class org.apache.hadoop.hbase.regionserver.AbstractMemStore
 
add(Cell, MemStoreSizing) - Method in class org.apache.hadoop.hbase.regionserver.HStore
Adds a value to the memstore
add(Cell, MemStoreSizing) - Method in interface org.apache.hadoop.hbase.regionserver.MemStore
Write an update
add(Delete) - Method in class org.apache.hadoop.hbase.client.RowMutations
Deprecated.
since 2.0 version and will be removed in 3.0 version. use RowMutations.add(Mutation)
add(Mutation) - Method in class org.apache.hadoop.hbase.client.RowMutations
Currently only supports Put and Delete mutations.
add(Put) - Method in class org.apache.hadoop.hbase.client.RowMutations
Deprecated.
since 2.0 version and will be removed in 3.0 version. use RowMutations.add(Mutation)
add(HDFSBlocksDistribution) - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution
This will add the distribution from input to this object
add(LruCachedBlock) - Method in class org.apache.hadoop.hbase.io.hfile.LruCachedBlockQueue
Attempt to add the specified cached block to this queue.
add(CallRunner) - Method in class org.apache.hadoop.hbase.ipc.AdaptiveLifoCoDelCallQueue
 
add(DataType<?>) - Method in class org.apache.hadoop.hbase.types.StructBuilder
Append field to the sequence of accumulated fields.
add(R) - Method in class org.apache.hadoop.hbase.util.RegionSplitCalculator
Adds an edge to the split calculator
add(S, S) - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
Returns sum or non null value among (if either of them is null); otherwise returns a null.
add(T) - Method in class org.apache.hadoop.hbase.util.LossyCounting
 
add(T) - Method in class org.apache.hadoop.hbase.util.ReservoirSample
 
addAll(int, Collection<? extends E>) - Method in class org.apache.hadoop.hbase.util.SortedList
 
addAll(Collection<? extends E>) - Method in class org.apache.hadoop.hbase.util.SortedList
 
addAll(Collection<? extends Runnable>) - Method in class org.apache.hadoop.hbase.thrift.CallQueue
 
addAll(Collection<? extends Cell>) - Method in class org.apache.hadoop.hbase.regionserver.CellSet
 
addAll(Collection<? extends CallRunner>) - Method in class org.apache.hadoop.hbase.ipc.AdaptiveLifoCoDelCallQueue
 
addAllLogsToSysTable(Connection) - Method in class org.apache.hadoop.hbase.namequeues.SlowLogPersistentService
Poll from queueForSysTable and insert 100 records in hbase:slowlog table in single batch
addAllServers(Collection<Address>) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
Adds the given servers to the group.
addAllSublists(List<? extends List<T>>) - Method in class org.apache.hadoop.hbase.util.ConcatenatedLists
 
addAllTables(Collection<TableName>) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
 
addAndGet(Result[], boolean) - Method in class org.apache.hadoop.hbase.client.BatchScanResultCache
 
addArchivedFiles(Set<Map.Entry<String, Long>>) - Method in interface org.apache.hadoop.hbase.quotas.FileArchiverNotifier
Records a file and its size in bytes being moved to the archive directory.
addArchivedFiles(Set<Map.Entry<String, Long>>) - Method in class org.apache.hadoop.hbase.quotas.FileArchiverNotifierImpl
 
addAttribute(AttributeKey<T>, T) - Method in class org.apache.hadoop.hbase.client.trace.ConnectionSpanBuilder
 
addAttribute(AttributeKey<T>, T) - Method in class org.apache.hadoop.hbase.server.trace.IpcServerSpanBuilder
 
addBytesMap(Map<Bytes, Bytes>) - Method in class org.apache.hadoop.hbase.CompoundConfiguration
Add Bytes map to config list.
addCallSize(long) - Method in class org.apache.hadoop.hbase.ipc.RpcServer
 
addCallSize(long) - Method in interface org.apache.hadoop.hbase.ipc.RpcServerInterface
Add/subtract from the current size of all outstanding calls.
addCellCount(int) - Method in class org.apache.hadoop.hbase.regionserver.MiniBatchOperationInProgress
 
addChangedReaderObserver(ChangedReadersObserver) - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
addClientMetris(UserMetrics.ClientMetrics) - Method in class org.apache.hadoop.hbase.UserMetricsBuilder
 
addClientPort(int) - Method in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
Add a client port to the list.
addClusterId(UUID) - Method in class org.apache.hadoop.hbase.wal.WALKeyImpl
Marks that the cluster with the given clusterId has consumed the change
addColumn(byte[]) - Method in class org.apache.hadoop.hbase.rest.RowSpec
 
addColumn(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Delete
Delete the latest version of the specified column.
addColumn(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Get
Get the column from the specific family with the specified qualifier.
addColumn(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.ImmutableScan
 
addColumn(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Scan
Get the column from the specified family with the specified qualifier.
addColumn(byte[], byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Append
Add the specified column and value to this Append operation.
addColumn(byte[], byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Put
Add the specified column and value to this Put operation.
addColumn(byte[], byte[], long) - Method in class org.apache.hadoop.hbase.client.Delete
Delete the specified version of the specified column.
addColumn(byte[], byte[], long) - Method in class org.apache.hadoop.hbase.client.Increment
Increment the column from the specific family with the specified qualifier by the specified amount.
addColumn(byte[], byte[], long, byte[]) - Method in class org.apache.hadoop.hbase.client.Put
Add the specified column and value, with the specified timestamp as its version to this Put operation.
addColumn(byte[], ByteBuffer, long, ByteBuffer) - Method in class org.apache.hadoop.hbase.client.Put
Add the specified column and value, with the specified timestamp as its version to this Put operation.
addColumn(TableName, ColumnFamilyDescriptor) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
As of release 2.0.0. This will be removed in HBase 3.0.0. Use Admin.addColumnFamily(TableName, ColumnFamilyDescriptor).
addColumn(TableName, ColumnFamilyDescriptor, long, long) - Method in class org.apache.hadoop.hbase.master.HMaster
 
addColumn(TableName, ColumnFamilyDescriptor, long, long) - Method in interface org.apache.hadoop.hbase.master.MasterServices
Add a new column to an existing table
addColumn(RpcController, MasterProtos.AddColumnRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
addColumn(RpcController, MasterProtos.AddColumnRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
 
addColumnFamily(ColumnFamilyDescriptor) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use TableDescriptorBuilder.setColumnFamily(ColumnFamilyDescriptor) instead
addColumnFamily(TableName, ColumnFamilyDescriptor) - Method in interface org.apache.hadoop.hbase.client.Admin
Add a column family to an existing table.
addColumnFamily(TableName, ColumnFamilyDescriptor) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Add a column family to an existing table.
addColumnFamilyAsync(TableName, ColumnFamilyDescriptor) - Method in interface org.apache.hadoop.hbase.client.Admin
Add a column family to an existing table.
addColumnFamilyAsync(TableName, ColumnFamilyDescriptor) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
addColumns(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Delete
Delete all versions of the specified column.
addColumns(byte[], byte[], long) - Method in class org.apache.hadoop.hbase.client.Delete
Delete all versions of the specified column with a timestamp less than or equal to the specified timestamp.
addColumns(Scan, byte[][]) - Static method in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
Adds an array of columns specified using old format, family:qualifier.
addCompactionResults(Collection<HStoreFile>, Collection<HStoreFile>) - Method in interface org.apache.hadoop.hbase.regionserver.StoreFileManager
Adds only the new compaction results into the structure.
addCompactionResults(Collection<HStoreFile>, Collection<HStoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
 
addConfiguration(String, String) - Method in class org.apache.hadoop.hbase.NamespaceDescriptor.Builder
 
addConfiguration(Map<String, String>) - Method in class org.apache.hadoop.hbase.NamespaceDescriptor.Builder
 
addCoprocessor(String) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use TableDescriptorBuilder.setCoprocessor(String) instead
addCoprocessor(String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
Add a table coprocessor to this table.
addCoprocessor(String, Path, int, Map<String, String>) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use TableDescriptorBuilder.setCoprocessor(CoprocessorDescriptor) instead
addCoprocessor(String, Path, int, Map<String, String>) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
Add a table coprocessor to this table.
addCoprocessorWithSpec(String) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use TableDescriptorBuilder.setCoprocessor(CoprocessorDescriptor) instead
addCoprocessorWithSpec(String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
Add a table coprocessor to this table.
addCostFuncInfo(String, double, float) - Method in class org.apache.hadoop.hbase.client.BalancerRejection.Builder
 
addDefaultApps(ContextHandlerCollection, String, Configuration) - Method in class org.apache.hadoop.hbase.http.HttpServer
Add default apps.
addDefaultServlets(ContextHandlerCollection, Configuration) - Method in class org.apache.hadoop.hbase.http.HttpServer
Add default servlets.
addDeleteFamilyBloomFilter(BloomFilterWriter) - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Writer
Store delete family Bloom filter in the file, which is only supported in HFile V2.
addDeleteFamilyBloomFilter(BloomFilterWriter) - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterImpl
 
addDeleteMarker(Cell) - Method in class org.apache.hadoop.hbase.client.Delete
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use Delete.add(Cell) instead
addDependencyJars(Configuration, Class<?>...) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Deprecated.
since 1.3.0 and will be removed in 3.0.0. Use TableMapReduceUtil.addDependencyJars(Job) instead.
addDependencyJars(JobConf) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
 
addDependencyJars(Job) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Add the HBase dependency jars as well as jars for any of the configured job classes to the job configuration, so that JobClient will ship them to the cluster and add them to the DistributedCache.
addDependencyJarsForClasses(Configuration, Class<?>...) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Add the jars containing the given classes to the job's configuration such that JobClient will ship them to the cluster and add them to the DistributedCache.
addEmptyLocation(Put, int) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
 
addEndpoint(URI) - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
Add an endpoint that the HTTP server should listen to.
addEntry(byte[], int, int) - Method in interface org.apache.hadoop.hbase.io.util.Dictionary
Adds an entry to the dictionary.
addEntry(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.util.LRUDictionary
 
addEntry(byte[], long, int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexWriter
Add one index entry to the current leaf-level block.
addEstimatedSize(long) - Method in class org.apache.hadoop.hbase.client.ClientAsyncPrefetchScanner
 
addEstimatedSize(long) - Method in class org.apache.hadoop.hbase.client.ClientScanner
 
addException(byte[], Throwable) - Method in class org.apache.hadoop.hbase.CacheEvictionStatsBuilder
 
addException(byte[], Throwable) - Method in class org.apache.hadoop.hbase.client.MultiResponse
 
addExtendedAttribute(String, byte[]) - Method in interface org.apache.hadoop.hbase.wal.WALKey
Add a named String value to this WALKey to be persisted into the WAL
addExtendedAttribute(String, byte[]) - Method in class org.apache.hadoop.hbase.wal.WALKeyImpl
 
addExtraHeader(String, String) - Method in class org.apache.hadoop.hbase.rest.client.Client
Add extra headers.
addFamily(byte[]) - Method in class org.apache.hadoop.hbase.client.Delete
Delete all versions of all columns of the specified family.
addFamily(byte[]) - Method in class org.apache.hadoop.hbase.client.Get
Get all columns from the specified family.
addFamily(byte[]) - Method in class org.apache.hadoop.hbase.client.ImmutableScan
 
addFamily(byte[]) - Method in class org.apache.hadoop.hbase.client.Scan
Get all columns from the specified family.
addFamily(byte[], long) - Method in class org.apache.hadoop.hbase.client.Delete
Delete all columns of the specified family with a timestamp less than or equal to the specified timestamp.
addFamily(HColumnDescriptor) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
Adds a column family.
addFamilyVersion(byte[], long) - Method in class org.apache.hadoop.hbase.client.Delete
Delete all columns of the specified family with a timestamp equal to the specified timestamp.
addFilter(String, boolean) - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenModel
 
addFilter(String, String, Map<String, String>) - Method in interface org.apache.hadoop.hbase.http.FilterContainer
Add a filter to the container.
addFilter(String, String, Map<String, String>) - Method in class org.apache.hadoop.hbase.http.HttpServer
 
addFilter(List<Filter>) - Method in class org.apache.hadoop.hbase.filter.FilterList
 
addFilter(Filter) - Method in class org.apache.hadoop.hbase.filter.FilterList
Add a filter.
addFilterAndArguments(Configuration, Class<? extends Filter>, List<String>) - Static method in class org.apache.hadoop.hbase.mapreduce.Import
Add a Filter to be instantiated on import
addFilterLists(List<Filter>) - Method in class org.apache.hadoop.hbase.filter.FilterListBase
 
addFilterLists(List<Filter>) - Method in class org.apache.hadoop.hbase.filter.FilterListWithAND
 
addFilterLists(List<Filter>) - Method in class org.apache.hadoop.hbase.filter.FilterListWithOR
 
addFilterPathMapping(String, WebAppContext) - Method in class org.apache.hadoop.hbase.http.HttpServer
Add the path spec to the filter path mapping.
addGeneralBloomFilter(BloomFilterWriter) - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Writer
Store general Bloom filter in the file.
addGeneralBloomFilter(BloomFilterWriter) - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterImpl
 
addGetResult(Result) - Method in class org.apache.hadoop.hbase.quotas.DefaultOperationQuota
 
addGetResult(Result) - Method in interface org.apache.hadoop.hbase.quotas.OperationQuota
Add a get result.
addGlobalFilter(String, String, Map<String, String>) - Method in interface org.apache.hadoop.hbase.http.FilterContainer
Add a global filter to the container - This global filter will be applied to all available web contexts.
addGlobalFilter(String, String, Map<String, String>) - Method in class org.apache.hadoop.hbase.http.HttpServer
 
addHBaseDependencyJars(Configuration) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Add HBase and its dependencies (only) to the job configuration.
addHbaseResources(Configuration) - Static method in class org.apache.hadoop.hbase.HBaseConfiguration
 
addHFileRefs(String, List<Pair<Path, Path>>) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueueStorage
Add new hfile references to the queue.
addHostsAndBlockWeight(String[], long) - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution
add some weight to a list of hosts, update the value of unique block weight
addHostsAndBlockWeight(String[], long, StorageType[]) - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution
add some weight to a list of hosts, update the value of unique block weight
addImmutable(byte[], byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Put
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use Put.add(Cell) and CellBuilder instead
addImmutable(byte[], byte[], long, byte[]) - Method in class org.apache.hadoop.hbase.client.Put
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use Put.add(Cell) and CellBuilder instead
addImmutable(byte[], ByteBuffer, long, ByteBuffer) - Method in class org.apache.hadoop.hbase.client.Put
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use Put.add(Cell) and CellBuilder instead
addInfo(String, SecurityInfo) - Static method in class org.apache.hadoop.hbase.security.SecurityInfo
Adds a security configuration for a new service name.
addInlineBlockWriter(InlineBlockWriter) - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Writer
Adds an inline block writer such as a multi-level block index writer or a compound Bloom filter writer.
addInlineBlockWriter(InlineBlockWriter) - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterImpl
 
addJerseyResourcePackage(String, String) - Method in class org.apache.hadoop.hbase.http.HttpServer
Add a Jersey resource package.
addLastBloomKey(HFile.Writer) - Method in class org.apache.hadoop.hbase.util.BloomContext
Adds the last bloom key to the HFile Writer as part of StorefileWriter close.
addLastBloomKey(HFile.Writer) - Method in class org.apache.hadoop.hbase.util.RowBloomContext
 
addLastBloomKey(HFile.Writer) - Method in class org.apache.hadoop.hbase.util.RowColBloomContext
 
addLease(LeaseManager.Lease) - Method in class org.apache.hadoop.hbase.regionserver.LeaseManager
Inserts lease.
addListener(CompletableFuture<T>, BiConsumer<? super T, ? super Throwable>) - Static method in class org.apache.hadoop.hbase.util.FutureUtils
This is method is used when you just want to add a listener to the given future.
addListener(CompletableFuture<T>, BiConsumer<? super T, ? super Throwable>, Executor) - Static method in class org.apache.hadoop.hbase.util.FutureUtils
Almost the same with FutureUtils.addListener(CompletableFuture, BiConsumer) method above, the only exception is that we will call CompletableFuture.whenCompleteAsync(BiConsumer, Executor).
addListener(ForeignExceptionListener) - Method in class org.apache.hadoop.hbase.errorhandling.ForeignExceptionDispatcher
Listen for failures to a given process.
addListener(Future<V>, GenericFutureListener<? extends Future<? super V>>) - Static method in class org.apache.hadoop.hbase.util.NettyFutureUtils
This is method is used when you just want to add a listener to the given netty future.
addLocation(Put, ServerName, long, int) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
 
addMaster() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
 
addMaster(Configuration, int) - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
 
addMaster(Configuration, int, User) - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
 
addMemStoreSize(long, long, long, int) - Method in class org.apache.hadoop.hbase.regionserver.RegionServicesForStores
 
addMetaWALSplit(long, long) - Method in class org.apache.hadoop.hbase.master.MetricsMasterFileSystem
Record a single instance of a split
addMethod(Method) - Method in class org.apache.hadoop.hbase.tool.coprocessor.CoprocessorMethods
 
addMethod(String, Class<?>...) - Method in class org.apache.hadoop.hbase.tool.coprocessor.CoprocessorMethods
 
addMethod(String, String...) - Method in class org.apache.hadoop.hbase.tool.coprocessor.CoprocessorMethods
 
addMobRegion(RegionInfo) - Method in class org.apache.hadoop.hbase.snapshot.SnapshotManifest
 
addMobRegion(RegionInfo, SnapshotManifest.RegionVisitor) - Method in class org.apache.hadoop.hbase.snapshot.SnapshotManifest
 
addMutation(Mutation) - Method in class org.apache.hadoop.hbase.quotas.DefaultOperationQuota
 
addMutation(Mutation) - Method in interface org.apache.hadoop.hbase.quotas.OperationQuota
Add a mutation result.
addMvccToOperationContext(long, long, long) - Method in class org.apache.hadoop.hbase.regionserver.ServerNonceManager
Store the write point in OperationContext when the operation succeed.
addNamespace(NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.namespace.NamespaceAuditor
 
addNamespaceQuota(Connection, String, QuotaProtos.Quotas) - Static method in class org.apache.hadoop.hbase.quotas.QuotaUtil
 
addOperationsFromCP(int, Mutation[]) - Method in class org.apache.hadoop.hbase.regionserver.MiniBatchOperationInProgress
Add more Mutations corresponding to the Mutation at the given index to be committed atomically in the same batch.
addOption(Option) - Method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
 
addOptions() - Method in class org.apache.hadoop.hbase.backup.BackupDriver
 
addOptions() - Method in class org.apache.hadoop.hbase.backup.RestoreDriver
 
addOptions() - Method in class org.apache.hadoop.hbase.mapreduce.RowCounter
 
addOptions() - Method in class org.apache.hadoop.hbase.snapshot.CreateSnapshot
 
addOptions() - Method in class org.apache.hadoop.hbase.snapshot.ExportSnapshot
 
addOptions() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo
 
addOptions() - Method in class org.apache.hadoop.hbase.tool.coprocessor.CoprocessorValidator
 
addOptions() - Method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
Override this to add command-line options using AbstractHBaseTool.addOptWithArg(java.lang.String, java.lang.String) and similar methods.
addOptions() - Method in class org.apache.hadoop.hbase.util.RegionMover
 
addOptions(Options) - Method in class org.apache.hadoop.hbase.thrift.ThriftServer
Add options to command lines
addOptNoArg(String, String) - Method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
 
addOptNoArg(String, String, String) - Method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
 
addOptWithArg(String, String) - Method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
 
addOptWithArg(String, String, String) - Method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
 
addPeer(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeers
Method called after a peer has been connected.
addPeer(String, ReplicationPeerConfig) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Deprecated.
use Admin.addReplicationPeer(String, ReplicationPeerConfig) instead
addPeer(String, ReplicationPeerConfig, boolean) - Method in class org.apache.hadoop.hbase.replication.FSReplicationPeerStorage
 
addPeer(String, ReplicationPeerConfig, boolean) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeerStorage
Add a replication peer.
addPeer(String, ReplicationPeerConfig, boolean) - Method in class org.apache.hadoop.hbase.replication.ZKReplicationPeerStorage
 
addPeer(String, ReplicationPeerConfig, Map<TableName, ? extends Collection<String>>) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Deprecated.
as release of 2.0.0, and it will be removed in 3.0.0, use ReplicationAdmin.addPeer(String, ReplicationPeerConfig) instead.
addPeerToHFileRefs(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueueStorage
Add a peer to hfile reference queue if peer does not exist.
addPrivilegedServlet(String, String, Class<? extends HttpServlet>) - Method in class org.apache.hadoop.hbase.http.HttpServer
Adds a servlet in the server that only administrators can access.
addPrivilegedServlet(String, String, Class<? extends HttpServlet>) - Method in class org.apache.hadoop.hbase.http.InfoServer
Adds a servlet in the server that any user can access.
addPrivilegedServlet(String, ServletHolder) - Method in class org.apache.hadoop.hbase.http.HttpServer
Adds a servlet in the server that only administrators can access.
addPutToKv(Put, Cell) - Method in class org.apache.hadoop.hbase.mapreduce.Import.Importer
 
addr - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient.RpcChannelImplementation
 
addReadRequestsCount(long) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
addRecord(NamedQueuePayload) - Method in class org.apache.hadoop.hbase.namequeues.NamedQueueRecorder
Add various NamedQueue records to ringbuffer.
addRegion(Path, RegionInfo) - Method in class org.apache.hadoop.hbase.snapshot.SnapshotManifest
Creates a 'manifest' for the specified region, by reading directly from the disk.
addRegion(Path, RegionInfo, SnapshotManifest.RegionVisitor) - Method in class org.apache.hadoop.hbase.snapshot.SnapshotManifest
 
addRegion(HRegion) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
addRegion(HRegion) - Method in interface org.apache.hadoop.hbase.regionserver.MutableOnlineRegions
Add to online regions.
addRegion(HRegion) - Method in class org.apache.hadoop.hbase.snapshot.SnapshotManifest
Creates a 'manifest' for the specified region, by reading directly from the HRegion object.
addRegion(HRegion, SnapshotManifest.RegionVisitor) - Method in class org.apache.hadoop.hbase.snapshot.SnapshotManifest
 
addRegionInfo(Put, RegionInfo) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
 
addRegionInfo(HbckRegionInfo) - Method in class org.apache.hadoop.hbase.util.HbckTableInfo
 
addRegionServer() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
 
addRegionServer(Configuration, int) - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
 
addRegionServer(Configuration, int, User) - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
 
addRegionServerQuota(Connection, String, QuotaProtos.Quotas) - Static method in class org.apache.hadoop.hbase.quotas.QuotaUtil
 
addRegionSize(RegionInfo, long, long) - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
 
addRegionsToMeta(Connection, List<RegionInfo>, int) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Adds a hbase:meta row for each of the specified new regions.
addRegionToMeta(Connection, RegionInfo) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Adds a (single) hbase:meta row for the specified new region and its daughters.
addRegionToSnapshot(SnapshotProtos.SnapshotDescription, ForeignExceptionSnare) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Complete taking the snapshot on the region.
addReplicas(List<RegionInfo>, int, int) - Static method in class org.apache.hadoop.hbase.client.RegionReplicaUtil
Create any replicas for the regions (the default replicas that was already created is passed to the method)
addReplicationBarrier(Put, long) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
See class comment on SerialReplicationChecker
addReplicationPeer(String, ReplicationPeerConfig) - Method in interface org.apache.hadoop.hbase.client.Admin
Add a new replication peer for replicating data to slave cluster.
addReplicationPeer(String, ReplicationPeerConfig) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Add a new replication peer for replicating data to slave cluster
addReplicationPeer(String, ReplicationPeerConfig, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
Add a new replication peer for replicating data to slave cluster.
addReplicationPeer(String, ReplicationPeerConfig, boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Add a new replication peer for replicating data to slave cluster
addReplicationPeer(String, ReplicationPeerConfig, boolean) - Method in class org.apache.hadoop.hbase.master.HMaster
 
addReplicationPeer(String, ReplicationPeerConfig, boolean) - Method in interface org.apache.hadoop.hbase.master.MasterServices
Add a new replication peer for replicating data to slave cluster
addReplicationPeer(RpcController, ReplicationProtos.AddReplicationPeerRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
addReplicationPeer(RpcController, ReplicationProtos.AddReplicationPeerRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
 
addReplicationPeerAsync(String, ReplicationPeerConfig) - Method in interface org.apache.hadoop.hbase.client.Admin
Add a new replication peer but does not block and wait for it.
addReplicationPeerAsync(String, ReplicationPeerConfig, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
Add a new replication peer but does not block and wait for it.
addReplicationPeerAsync(String, ReplicationPeerConfig, boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
addRequiredOption(Option) - Method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
 
addRequiredOptWithArg(String, String) - Method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
 
addRequiredOptWithArg(String, String, String) - Method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
 
addResource(InputStream) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
 
addResource(InputStream, String) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
 
addResource(String) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
 
addResource(URL) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
 
addResource(Configuration) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
 
addResource(Path) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
 
address - Variable in class org.apache.hadoop.hbase.ipc.SimpleRpcServer
Deprecated.
 
org.apache.hadoop.hbase.net.Address - Class in org.apache.hadoop.hbase.net
An immutable type to hold a hostname and port combo, like an Endpoint or java.net.InetSocketAddress (but without danger of our calling resolve -- we do NOT want a resolve happening every time we want to hold a hostname and port combo).
org.apache.hadoop.hbase.util.Addressing - Class in org.apache.hadoop.hbase.util
Utility for network addresses, resolving and naming.
Addressing() - Constructor for class org.apache.hadoop.hbase.util.Addressing
 
org.apache.hadoop.hbase.util.Addressing.AddressSelectionCondition - Interface in org.apache.hadoop.hbase.util
Interface for AddressSelectionCondition to check if address is acceptable
addRSGroup(String) - Method in interface org.apache.hadoop.hbase.rsgroup.RSGroupAdmin
Creates a new RegionServer group with the given name.
addRSGroup(String) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminClient
 
addRSGroup(String) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminServer
 
addRSGroup(RSGroupInfo) - Method in interface org.apache.hadoop.hbase.rsgroup.RSGroupInfoManager
Add given RSGroupInfo to existing list of group infos.
addScanner(ResultScanner, boolean) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
Assigns a unique ID to the scanner and adds the mapping to an internal hash-map.
addScanResult(List<Result>) - Method in class org.apache.hadoop.hbase.quotas.DefaultOperationQuota
 
addScanResult(List<Result>) - Method in interface org.apache.hadoop.hbase.quotas.OperationQuota
Add a scan result.
addServer(RegionInfo, ServerName) - Method in class org.apache.hadoop.hbase.util.HbckRegionInfo
 
addServer(Address) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
Adds the given server to the group.
addServer(ServerName) - Method in class org.apache.hadoop.hbase.util.HbckTableInfo
 
addServerToDrainList(ServerName) - Method in class org.apache.hadoop.hbase.master.ServerManager
Add the server to the drain list.
addServlet(String, String, Class<? extends HttpServlet>) - Method in class org.apache.hadoop.hbase.http.InfoServer
Deprecated.
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.
addShutdownHook(Thread, int) - Method in class org.apache.hadoop.hbase.util.ShutdownHookManager
 
addSlowLogRecords(List<TooSlowLog.SlowLogPayload>, Connection) - Static method in class org.apache.hadoop.hbase.slowlog.SlowLogTableAccessor
Add slow/large log records to hbase:slowlog table
addSnapshot(long) - Method in class org.apache.hadoop.hbase.master.MetricsSnapshot
Record a single instance of a snapshot
addSnapshotClone(long) - Method in class org.apache.hadoop.hbase.master.MetricsSnapshot
Record a single instance of a snapshot cloned table
addSnapshotRestore(long) - Method in class org.apache.hadoop.hbase.master.MetricsSnapshot
Record a single instance of a snapshot
addSplit(long, long) - Method in class org.apache.hadoop.hbase.master.MetricsMasterFileSystem
Record a single instance of a split
addSplitsToParent(Connection, RegionInfo, RegionInfo, RegionInfo) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Adds daughter region infos to hbase:meta row for the specified region.
addStatistic(byte[], ClientProtos.RegionLoadStats) - Method in class org.apache.hadoop.hbase.client.MultiResponse
 
addStoreFiles(Collection<HStoreFile>, StoreEngine.IOExceptionRunnable) - Method in class org.apache.hadoop.hbase.regionserver.StoreEngine
Add the store files to store file manager, and also record it in the store file tracker.
addStringMap(Map<String, String>) - Method in class org.apache.hadoop.hbase.CompoundConfiguration
Add String map to config list.
addSublist(List<T>) - Method in class org.apache.hadoop.hbase.util.ConcatenatedLists
 
addTable(TableName) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
 
addTableDescriptor(TableDescriptor) - Method in class org.apache.hadoop.hbase.snapshot.SnapshotManifest
Add the table descriptor to the snapshot manifest
addTableQuota(Connection, TableName, QuotaProtos.Quotas) - Static method in class org.apache.hadoop.hbase.quotas.QuotaUtil
 
addTables(TableName[]) - Method in class org.apache.hadoop.hbase.backup.BackupInfo
 
addToBackupSet(String, TableName[]) - Method in interface org.apache.hadoop.hbase.backup.BackupAdmin
Add tables to backup set command
addToFailedServers(Address, Throwable) - Method in class org.apache.hadoop.hbase.ipc.FailedServers
Add an address to the list of the failed servers list.
addToHDFSBlocksDistribution(HDFSBlocksDistribution, BlockLocation[]) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Update blocksDistribution with blockLocations
addToken(Token<? extends TokenIdentifier>) - Method in class org.apache.hadoop.hbase.security.User
Adds the given Token to the user's credentials.
addToQueueForSysTable(TooSlowLog.SlowLogPayload) - Method in class org.apache.hadoop.hbase.namequeues.SlowLogPersistentService
 
addToScanners(List<? extends Segment>, long, List<KeyValueScanner>) - Static method in class org.apache.hadoop.hbase.regionserver.AbstractMemStore
 
addToScanners(Segment, long, List<KeyValueScanner>) - Static method in class org.apache.hadoop.hbase.regionserver.AbstractMemStore
 
addTypeFilter(QuotaType) - Method in class org.apache.hadoop.hbase.quotas.QuotaFilter
Add a type to the filter list
addUnprivilegedServlet(String, String, Class<? extends HttpServlet>) - Method in class org.apache.hadoop.hbase.http.HttpServer
Adds a servlet in the server that any user can access.
addUnprivilegedServlet(String, String, Class<? extends HttpServlet>) - Method in class org.apache.hadoop.hbase.http.InfoServer
Adds a servlet in the server that any user can access.
addUnprivilegedServlet(String, String, ServletHolder) - Method in class org.apache.hadoop.hbase.http.InfoServer
Adds a servlet in the server that any user can access.
addUnprivilegedServlet(String, ServletHolder) - Method in class org.apache.hadoop.hbase.http.HttpServer
Adds a servlet in the server that any user can access.
addUsedSplitWALWorker(ServerName) - Method in class org.apache.hadoop.hbase.master.SplitWALManager
When master restart, there will be a new splitWorkerAssigner.
addUsedWorker(ServerName) - Method in class org.apache.hadoop.hbase.master.WorkerAssigner
 
addUserQuota(Connection, String, String, QuotaProtos.Quotas) - Static method in class org.apache.hadoop.hbase.quotas.QuotaUtil
 
addUserQuota(Connection, String, QuotaProtos.Quotas) - Static method in class org.apache.hadoop.hbase.quotas.QuotaUtil
 
addUserQuota(Connection, String, TableName, QuotaProtos.Quotas) - Static method in class org.apache.hadoop.hbase.quotas.QuotaUtil
 
addVersionDelete(Cell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.NewVersionBehaviorTracker.DeleteVersionsNode
 
addWAL(ServerName, String, String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueueStorage
Add a new WAL file to the given queue for a given regionserver.
addWAL(WAL) - Method in class org.apache.hadoop.hbase.wal.AbstractWALRoller
 
addWALActionsListener(WALActionsListener) - Method in class org.apache.hadoop.hbase.wal.AbstractFSWALProvider
 
addWALActionsListener(WALActionsListener) - Method in class org.apache.hadoop.hbase.wal.RegionGroupingProvider
 
addWALActionsListener(WALActionsListener) - Method in interface org.apache.hadoop.hbase.wal.WALProvider
Add a WALActionsListener.
addWalEventTrackerRows(Queue<WALEventTrackerPayload>, Connection) - Static method in class org.apache.hadoop.hbase.namequeues.WALEventTrackerTableAccessor
Add wal event tracker rows to hbase:waleventtracker table
addWeight(long, long) - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution.HostAndWeight
add weight
addWriteRequestsCount(long) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
adjustFieldLength() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenPresenter
 
org.apache.hadoop.hbase.client.Admin - Interface in org.apache.hadoop.hbase.client
The administrative API for HBase.
ADMIN_QOS - Static variable in class org.apache.hadoop.hbase.HConstants
 
org.apache.hadoop.hbase.http.AdminAuthorizedFilter - Class in org.apache.hadoop.hbase.http
 
AdminAuthorizedFilter() - Constructor for class org.apache.hadoop.hbase.http.AdminAuthorizedFilter
 
org.apache.hadoop.hbase.http.AdminAuthorizedServlet - Class in org.apache.hadoop.hbase.http
General servlet which is admin-authorized.
AdminAuthorizedServlet() - Constructor for class org.apache.hadoop.hbase.http.AdminAuthorizedServlet
 
ADMINS_ACL - Static variable in class org.apache.hadoop.hbase.http.HttpServer
 
advance() - Method in interface org.apache.hadoop.hbase.CellScanner
Advance the scanner 1 cell.
advance() - Method in class org.apache.hadoop.hbase.client.Result
 
advance() - Method in class org.apache.hadoop.hbase.codec.BaseDecoder
 
advance() - Method in class org.apache.hadoop.hbase.codec.KeyValueCodec.ByteBuffKeyValueDecoder
 
org.apache.hadoop.hbase.client.AdvancedScanResultConsumer - Interface in org.apache.hadoop.hbase.client
This is the low level API for asynchronous scan.
org.apache.hadoop.hbase.client.AdvancedScanResultConsumer.ScanController - Interface in org.apache.hadoop.hbase.client
Used to suspend or stop a scan, or get a scan cursor if available.
org.apache.hadoop.hbase.client.AdvancedScanResultConsumer.ScanResumer - Interface in org.apache.hadoop.hbase.client
Used to resume a scan.
advanceTo(long) - Method in class org.apache.hadoop.hbase.regionserver.MultiVersionConcurrencyControl
Step the MVCC forward on to a new read/write basis.
org.apache.hadoop.hbase.io.crypto.aes.AES - Class in org.apache.hadoop.hbase.io.crypto.aes
AES-128, provided by the JCE
AES(CipherProvider) - Constructor for class org.apache.hadoop.hbase.io.crypto.aes.AES
 
org.apache.hadoop.hbase.io.crypto.aes.AESDecryptor - Class in org.apache.hadoop.hbase.io.crypto.aes
 
AESDecryptor(Cipher) - Constructor for class org.apache.hadoop.hbase.io.crypto.aes.AESDecryptor
 
org.apache.hadoop.hbase.io.crypto.aes.AESEncryptor - Class in org.apache.hadoop.hbase.io.crypto.aes
 
AESEncryptor(Cipher, SecureRandom) - Constructor for class org.apache.hadoop.hbase.io.crypto.aes.AESEncryptor
 
affixShutdownHook(Thread, int) - Static method in class org.apache.hadoop.hbase.util.ShutdownHookManager
 
afterCreatingZigZagLatch() - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
Used to manufacture race condition reliably.
afterDecodingKeyValue(DataInputStream, ByteBuffer, HFileBlockDefaultDecodingContext) - Method in class org.apache.hadoop.hbase.io.encoding.CopyKeyDataBlockEncoder
 
afterEncodingKeyValue(Cell, DataOutputStream, HFileBlockDefaultEncodingContext) - Method in class org.apache.hadoop.hbase.io.encoding.CopyKeyDataBlockEncoder
Returns unencoded size added
afterExecute(Runnable, Throwable) - Method in class org.apache.hadoop.hbase.thrift.THBaseThreadPoolExecutor
 
afterExecution() - Method in interface org.apache.hadoop.hbase.regionserver.FlushLifeCycleTracker
Called after flush is executed.
afterWALArchive(Path, Path) - Method in class org.apache.hadoop.hbase.wal.AbstractWALRoller
 
org.apache.hadoop.hbase.io.hfile.AgeSnapshot - Class in org.apache.hadoop.hbase.io.hfile
Snapshot of block cache age in cache.
aggregateRecords(List<Record>, Field) - Static method in class org.apache.hadoop.hbase.hbtop.mode.ModeStrategyUtils
Group by records on the basis of supplied groupBy field and Aggregate records using Record.combine(Record)
align(int) - Static method in class org.apache.hadoop.hbase.util.ClassSize
Aligns a number to 8.
align(long) - Static method in class org.apache.hadoop.hbase.util.ClassSize
Aligns a number to 8.
ALL - Enum constant in enum org.apache.hadoop.hbase.client.AsyncProcessTask.SubmittedRows
 
ALL - Enum constant in enum org.apache.hadoop.hbase.MetaTableAccessor.QueryType
 
ALL_CATEGORIES - Enum constant in enum org.apache.hadoop.hbase.io.hfile.BlockType.BlockCategory
 
ALL_VERSIONS - Static variable in class org.apache.hadoop.hbase.HConstants
Define for 'return-all-versions'.
allBufs - Variable in class org.apache.hadoop.hbase.io.ByteBufferListOutputStream
 
alloc(int) - Method in class org.apache.hadoop.hbase.regionserver.Chunk
Try to allocate size bytes from the chunk.
allocate(int) - Method in class org.apache.hadoop.hbase.io.ByteBuffAllocator
Allocate size bytes from the ByteBufAllocator, Note to call the ByteBuff.release() if no need any more, otherwise the memory leak happen in NIO ByteBuffer pool.
allocate(long) - Method in interface org.apache.hadoop.hbase.util.ByteBufferAllocator
Allocates a bytebuffer
allocateOneBuffer() - Method in class org.apache.hadoop.hbase.io.ByteBuffAllocator
Allocate an buffer with buffer size from ByteBuffAllocator, Note to call the ByteBuff.release() if no need any more, otherwise the memory leak happen in NIO ByteBuffer pool.
ALLOCATOR_POOL_ENABLED_KEY - Static variable in class org.apache.hadoop.hbase.io.ByteBuffAllocator
 
allocBloom() - Method in class org.apache.hadoop.hbase.util.BloomFilterChunk
 
allocCount - Variable in class org.apache.hadoop.hbase.regionserver.Chunk
Total number of allocations satisfied from this buffer
allOf(List<CompletableFuture<T>>) - Static method in class org.apache.hadoop.hbase.util.FutureUtils
Returns a new CompletableFuture that is completed when all of the given CompletableFutures complete.
allowCompaction - Variable in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
 
allowFallbackToSimpleAuth - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
 
allTime() - Static method in class org.apache.hadoop.hbase.io.TimeRange
 
AND - Enum constant in enum org.apache.hadoop.hbase.client.LogQueryFilter.FilterByOperator
Deprecated.
 
AND - Enum constant in enum org.apache.hadoop.hbase.filter.BitComparator.BitwiseOp
and
AND - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
AND Byte Array
AND_ARRAY - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
AND Array
AND_BUFFER - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
 
annotatedQos - Variable in class org.apache.hadoop.hbase.regionserver.AnnotationReadingPriorityFunction
 
org.apache.hadoop.hbase.regionserver.AnnotationReadingPriorityFunction - Class in org.apache.hadoop.hbase.regionserver
Reads special method annotations and table names to figure a priority for use by QoS facility in ipc; e.g: rpcs to hbase:meta get priority.
AnnotationReadingPriorityFunction(RSRpcServices) - Constructor for class org.apache.hadoop.hbase.regionserver.AnnotationReadingPriorityFunction
Calls AnnotationReadingPriorityFunction(RSRpcServices, Class) using the result of rpcServices#getClass() The RPC server implementation
AnnotationReadingPriorityFunction(RSRpcServices, Class<? extends RSRpcServices>) - Constructor for class org.apache.hadoop.hbase.regionserver.AnnotationReadingPriorityFunction
Constructs the priority function given the RPC server implementation and the annotations on the methods in the provided clz.
ANY - Enum constant in enum org.apache.hadoop.hbase.backup.BackupInfo.BackupState
 
ANY - Enum constant in enum org.apache.hadoop.hbase.regionserver.Region.Operation
 
APP_DIR - Static variable in class org.apache.hadoop.hbase.http.HttpServer
 
appDir - Variable in class org.apache.hadoop.hbase.http.HttpServer
 
append(byte[], byte[], boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileInfo
Append the given key/value pair to the file info, optionally checking the key prefix.
append(CacheEvictionStats) - Method in class org.apache.hadoop.hbase.CacheEvictionStatsAggregator
 
append(CacheEvictionStats) - Method in class org.apache.hadoop.hbase.CacheEvictionStatsBuilder
 
append(Cell) - Method in class org.apache.hadoop.hbase.io.hfile.CompoundBloomFilterWriter
 
append(Cell) - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterImpl
Add key/value to file.
append(Cell) - Method in interface org.apache.hadoop.hbase.regionserver.CellSink
Append the given cell
append(Cell) - Method in class org.apache.hadoop.hbase.regionserver.DateTieredMultiFileWriter
 
append(Cell) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileWriter
 
append(Cell) - Method in class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter.BoundaryMultiWriter
 
append(Cell) - Method in class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter.SizeMultiWriter
 
append(Append) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
Appends values to one or more columns within a single row.
append(Append) - Method in class org.apache.hadoop.hbase.client.HTable
 
append(Append) - Method in interface org.apache.hadoop.hbase.client.Table
Appends values to one or more columns within a single row.
append(Append) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
append(Append) - Method in interface org.apache.hadoop.hbase.regionserver.Region
Perform one or more append operations on a row.
append(Append, long, long) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
append(RegionInfo, WALKeyImpl, WALEdit, boolean) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
Append a set of edits to the WAL.
append(RegionInfo, WALKeyImpl, WALEdit, boolean) - Method in class org.apache.hadoop.hbase.regionserver.wal.AsyncFSWAL
 
append(RegionInfo, WALKeyImpl, WALEdit, boolean) - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
 
append(TAppend) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
 
append(EntryBuffers.RegionEntryBuffer) - Method in class org.apache.hadoop.hbase.wal.BoundedRecoveredHFilesOutputSink
 
append(EntryBuffers.RegionEntryBuffer) - Method in class org.apache.hadoop.hbase.wal.OutputSink
 
append(WAL.Entry) - Method in class org.apache.hadoop.hbase.regionserver.wal.AsyncProtobufLogWriter
 
append(WAL.Entry) - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogWriter
 
append(WAL.Entry) - Method in interface org.apache.hadoop.hbase.wal.WALProvider.AsyncWriter
 
append(WAL.Entry) - Method in interface org.apache.hadoop.hbase.wal.WALProvider.Writer
 
append(TNode, TNode) - Static method in class org.apache.hadoop.hbase.util.AvlUtil.AvlIterableList
Append a node to the tree
org.apache.hadoop.hbase.client.Append - Class in org.apache.hadoop.hbase.client
Performs Append operations on a single row.
Append(byte[]) - Constructor for class org.apache.hadoop.hbase.client.Append
Create a Append operation for the specified row.
Append(byte[], int, int) - Constructor for class org.apache.hadoop.hbase.client.Append
Create a Append operation for the specified row.
Append(byte[], long, NavigableMap<byte[], List<Cell>>) - Constructor for class org.apache.hadoop.hbase.client.Append
Construct the Append with user defined data.
Append(Append) - Constructor for class org.apache.hadoop.hbase.client.Append
Copy constructor
APPEND - Enum constant in enum org.apache.hadoop.hbase.coprocessor.RegionObserver.MutationType
 
APPEND - Enum constant in enum org.apache.hadoop.hbase.regionserver.Region.Operation
 
APPEND_BLOCK_BYTES_SCANNED_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
APPEND_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
 
APPEND_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
 
APPEND_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
APPEND_SIZE - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
 
APPEND_SIZE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
 
APPEND_TIME - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
 
APPEND_TIME_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
 
appendData(RegionInfo, WALKeyImpl, WALEdit) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
 
appendData(RegionInfo, WALKeyImpl, WALEdit) - Method in interface org.apache.hadoop.hbase.wal.WAL
Append a set of data edits to the WAL.
appendEntry(WAL.Entry) - Method in class org.apache.hadoop.hbase.wal.EntryBuffers
Append a log entry into the corresponding region buffer.
appendEntry(W, FSWALEntry) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
 
appendExcludeTableCFsToReplicationPeerConfig(Map<TableName, List<String>>, ReplicationPeerConfig) - Static method in class org.apache.hadoop.hbase.client.replication.ReplicationPeerConfigUtil
 
appendFileInfo(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Writer
Add an element to the file info map.
appendFileInfo(byte[], byte[]) - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterImpl
Add to the file info.
appendFileInfo(byte[], byte[]) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileWriter
 
appendFromThrift(TAppend) - Static method in class org.apache.hadoop.hbase.thrift.ThriftUtilities
From a TAppend create an Append.
appendKeyTo(Cell, byte[], int) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
 
appendKeyTo(Cell, ByteBuffer, int) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
 
appendKeyValue(StringBuilder, String, Object) - Static method in class org.apache.hadoop.hbase.util.Strings
Append to a StringBuilder a key/value.
appendKeyValue(StringBuilder, String, Object, String, String) - Static method in class org.apache.hadoop.hbase.util.Strings
Append to a StringBuilder a key/value.
appendList(TNode, TNode) - Static method in class org.apache.hadoop.hbase.util.AvlUtil.AvlIterableList
Append a list of nodes to the tree
appendMarker(RegionInfo, WALKeyImpl, WALEdit) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
 
appendMarker(RegionInfo, WALKeyImpl, WALEdit) - Method in interface org.apache.hadoop.hbase.wal.WAL
Append an operational 'meta' event marker edit to the WAL.
appendMetaBlock(String, Writable) - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Writer
 
appendMetaBlock(String, Writable) - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterImpl
Add a meta block to the end of the file.
appendMetadata(long, boolean) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileWriter
Writes meta data.
appendMetadata(long, boolean, long) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileWriter
Writes meta data.
appendMetadata(long, boolean, Collection<HStoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileWriter
Writes meta data.
appendMetaData(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKMetadata
 
appendMobMetadata(SetMultimap<TableName, String>) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileWriter
Appends MOB - specific metadata (even if it is empty)
appendPeerTableCFs(String, String) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Deprecated.
as release of 2.0.0, and it will be removed in 3.0.0, use ReplicationAdmin.appendPeerTableCFs(String, Map) instead.
appendPeerTableCFs(String, Map<TableName, ? extends Collection<String>>) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Deprecated.
appendReplicationPeerTableCFs(String, Map<TableName, List<String>>) - Method in interface org.apache.hadoop.hbase.client.Admin
Append the replicable table column family config from the specified peer.
appendReplicationPeerTableCFs(String, Map<TableName, List<String>>) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Append the replicable table-cf config of the specified peer
appendTableCFsToReplicationPeerConfig(Map<TableName, List<String>>, ReplicationPeerConfig) - Static method in class org.apache.hadoop.hbase.client.replication.ReplicationPeerConfigUtil
 
appendTo(Cell, ByteBuffer, int, boolean) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
Copy the Cell content into the passed buf in KeyValue serialization format.
appendToByteArray(Cell, byte[], int, boolean) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
copy key and value
appendToByteBuffer(ByteBuffer, KeyValue, boolean) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
 
appendTrackedTimestampsToMetadata() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileWriter
Add TimestampRange and earliest put timestamp to Metadata
apply(byte) - Method in enum org.apache.hadoop.hbase.util.Order
Apply order to the byte val.
apply(byte[]) - Method in enum org.apache.hadoop.hbase.util.Order
Apply order to the byte array val.
apply(byte[], int, int) - Method in enum org.apache.hadoop.hbase.util.Order
Apply order to a range within the byte array val.
apply(BackupInfo) - Method in interface org.apache.hadoop.hbase.backup.BackupInfo.Filter
Filter interface
applyFilterAndGet(List<Record>, List<RecordFilter>) - Static method in class org.apache.hadoop.hbase.hbtop.mode.ModeStrategyUtils
Filter records as per the supplied filters,
archive(String) - Method in class org.apache.hadoop.hbase.master.SplitWALManager
Archive processed WAL
archive(Pair<Path, Long>) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
 
archiveFamily(FileSystem, Configuration, RegionInfo, Path, byte[]) - Static method in class org.apache.hadoop.hbase.backup.HFileArchiver
Remove from the specified region the store files of the specified column family, either by archiving them or outright deletion
archiveFamilyByFamilyDir(FileSystem, Configuration, RegionInfo, Path, byte[]) - Static method in class org.apache.hadoop.hbase.backup.HFileArchiver
Removes from the specified region the store files of the specified column family, either by archiving them or outright deletion
archiveLogFile(Path) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
 
archiveMetaLog(ServerName) - Method in class org.apache.hadoop.hbase.master.MasterWalManager
The hbase:meta region may OPEN and CLOSE without issue on a server and then move elsewhere.
archiveMobFiles(Configuration, TableName, byte[], List<Path>) - Method in class org.apache.hadoop.hbase.mob.RSMobFileCleanerChore
Archives the mob files.
archiveRecoveredEdits(String, Collection<HStoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.HRegionWALFileSystem
Closes and archives the specified store files from the specified family.
archiveRecoveredEdits(Configuration, FileSystem, RegionInfo, byte[], Collection<HStoreFile>) - Static method in class org.apache.hadoop.hbase.backup.HFileArchiver
Archive recovered edits using existing logic for archiving store files.
archiveRegion(Configuration, FileSystem, RegionInfo) - Static method in class org.apache.hadoop.hbase.backup.HFileArchiver
Cleans up all the files for a HRegion by archiving the HFiles to the archive directory
archiveRegion(FileSystem, Path, Path, Path) - Static method in class org.apache.hadoop.hbase.backup.HFileArchiver
Remove an entire region from the table directory via archiving the region's hfiles.
archiveRegions(Configuration, FileSystem, Path, Path, List<Path>) - Static method in class org.apache.hadoop.hbase.backup.HFileArchiver
Archive the specified regions in parallel.
archiveStoreFile(Configuration, FileSystem, RegionInfo, Path, byte[], Path) - Static method in class org.apache.hadoop.hbase.backup.HFileArchiver
Archive the store file
archiveStoreFiles(Configuration, FileSystem, RegionInfo, Path, byte[], Collection<HStoreFile>) - Static method in class org.apache.hadoop.hbase.backup.HFileArchiver
Remove the store files, either by archiving them or outright deletion
areAdjacent(RegionInfo, RegionInfo) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
Check whether two regions are adjacent; i.e.
areAdjacent(HRegionInfo, HRegionInfo) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionInfo.areAdjacent(RegionInfo, RegionInfo).
areCompactionsDisabled() - Method in class org.apache.hadoop.hbase.quotas.policies.AbstractViolationPolicyEnforcement
 
areCompactionsDisabled() - Method in class org.apache.hadoop.hbase.quotas.policies.NoWritesCompactionsViolationPolicyEnforcement
 
areCompactionsDisabled() - Method in interface org.apache.hadoop.hbase.quotas.SpaceViolationPolicyEnforcement
Returns whether or not compactions on this table should be disabled for this policy.
areCompactionsDisabled(TableName) - Method in class org.apache.hadoop.hbase.quotas.RegionServerSpaceQuotaManager
Returns whether or not compactions should be disabled for the given tableName per a space quota violation policy.
areDeadServersInProgress() - Method in class org.apache.hadoop.hbase.master.ServerManager
Checks if any dead servers are currently in progress.
arePartsEqual(ByteBuffer, int, int, int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
Deprecated.
Check whether two parts in the same buffer are equal.
areScanStartRowAndStopRowEqual(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.client.ClientUtil
 
areWritesEnabled() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
areWritesEnabled() - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
areWritesEnabled() - Method in interface org.apache.hadoop.hbase.regionserver.Store
 
Args(TServerTransport, Configuration) - Constructor for class org.apache.hadoop.hbase.thrift.TBoundedThreadPoolServer.Args
 
array() - Method in class org.apache.hadoop.hbase.nio.ByteBuff
Returns the byte[] if the underlying BB has single BB and hasArray true
array() - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
 
array() - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
 
ARRAY - Static variable in class org.apache.hadoop.hbase.util.ClassSize
Array overhead
ARRAY_MAP - Enum constant in enum org.apache.hadoop.hbase.regionserver.CompactingMemStore.IndexType
 
org.apache.hadoop.hbase.ArrayBackedTag - Class in org.apache.hadoop.hbase
This is a Tag implementation in which value is backed by an on heap byte array.
ArrayBackedTag(byte[], int) - Constructor for class org.apache.hadoop.hbase.ArrayBackedTag
Creates a Tag from the specified byte array and offset.
ArrayBackedTag(byte[], int, int) - Constructor for class org.apache.hadoop.hbase.ArrayBackedTag
Creates a Tag from the specified byte array, starting at offset, and for length length.
ArrayBackedTag(byte, byte[]) - Constructor for class org.apache.hadoop.hbase.ArrayBackedTag
Format for a tag : <length of tag - 2 bytes><type code - 1 byte><tag> tag length is serialized using 2 bytes only but as this will be unsigned, we can have max tag length of (Short.MAX_SIZE * 2) +1.
ArrayBackedTag(byte, String) - Constructor for class org.apache.hadoop.hbase.ArrayBackedTag
The special tag will write the length of each tag and that will be followed by the type and then the actual tag.
ARRAYLIST - Static variable in class org.apache.hadoop.hbase.util.ClassSize
Overhead for ArrayList(0)
arrayOffset() - Method in class org.apache.hadoop.hbase.nio.ByteBuff
Returns the arrayOffset of the byte[] incase of a single BB backed ByteBuff
arrayOffset() - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
 
arrayOffset() - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
 
arrowDown() - Method in class org.apache.hadoop.hbase.hbtop.screen.field.FieldScreenPresenter
 
arrowDown() - Method in class org.apache.hadoop.hbase.hbtop.screen.mode.ModeScreenPresenter
 
arrowDown() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.InputModeScreenPresenter
 
arrowDown() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.Paging
 
arrowDown() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenPresenter
 
ArrowDown - Enum constant in enum org.apache.hadoop.hbase.hbtop.terminal.KeyPress.Type
 
arrowLeft() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.InputModeScreenPresenter
 
arrowLeft() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenPresenter
 
ArrowLeft - Enum constant in enum org.apache.hadoop.hbase.hbtop.terminal.KeyPress.Type
 
arrowRight() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.InputModeScreenPresenter
 
arrowRight() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenPresenter
 
ArrowRight - Enum constant in enum org.apache.hadoop.hbase.hbtop.terminal.KeyPress.Type
 
arrowUp() - Method in class org.apache.hadoop.hbase.hbtop.screen.field.FieldScreenPresenter
 
arrowUp() - Method in class org.apache.hadoop.hbase.hbtop.screen.mode.ModeScreenPresenter
 
arrowUp() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.InputModeScreenPresenter
 
arrowUp() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.Paging
 
arrowUp() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenPresenter
 
ArrowUp - Enum constant in enum org.apache.hadoop.hbase.hbtop.terminal.KeyPress.Type
 
ASCENDING - Enum constant in enum org.apache.hadoop.hbase.util.Order
 
ASCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedBlob
 
ASCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedBlobVar
 
ASCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedFloat32
 
ASCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedFloat64
 
ASCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedInt16
 
ASCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedInt32
 
ASCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedInt64
 
ASCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedInt8
 
ASCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedNumeric
 
ASCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedString
 
ASCENDING - Static variable in class org.apache.hadoop.hbase.types.RawBytes
 
ASCENDING - Static variable in class org.apache.hadoop.hbase.types.RawString
 
asFloat() - Method in class org.apache.hadoop.hbase.hbtop.field.FieldValue
 
asInt() - Method in class org.apache.hadoop.hbase.hbtop.field.FieldValue
 
asInterrupt(Throwable) - Static method in class org.apache.hadoop.hbase.util.ExceptionUtil
Returns an InterruptedIOException if t was an interruption, null otherwise
asList(byte[], int, int) - Static method in class org.apache.hadoop.hbase.TagUtil
Creates list of tags from given byte array, expected that it is in the expected tag format.
asLong() - Method in class org.apache.hadoop.hbase.hbtop.field.FieldValue
 
assertBulkLoadHFileOk(Path) - Method in class org.apache.hadoop.hbase.regionserver.HStore
This throws a WrongRegionException if the HFile does not fit in this region, or an InvalidHFileException if the HFile is not valid.
assertSeeked() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
 
assertSnapshotRequestIsValid(SnapshotProtos.SnapshotDescription) - Static method in class org.apache.hadoop.hbase.snapshot.ClientSnapshotDescriptionUtils
Check to make sure that the description of the snapshot requested is valid
assign(byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
Assign a Region.
assign(byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Assign an individual region.
assign(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
ASSIGN_METRIC_PREFIX - Static variable in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
 
ASSIGN_RANDOM_PORTS - Static variable in class org.apache.hadoop.hbase.LocalHBaseCluster
 
org.apache.hadoop.hbase.master.AssignmentVerificationReport - Class in org.apache.hadoop.hbase.master
Helper class that is used by RegionPlacementMaintainer to print information for favored nodes
AssignmentVerificationReport() - Constructor for class org.apache.hadoop.hbase.master.AssignmentVerificationReport
 
assignRegion(RpcController, MasterProtos.AssignRegionRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
assignRegion(RpcController, MasterProtos.AssignRegionRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
 
assigns(List<String>) - Method in interface org.apache.hadoop.hbase.client.Hbck
 
assigns(List<String>, boolean) - Method in class org.apache.hadoop.hbase.client.HBaseHbck
 
assigns(List<String>, boolean) - Method in interface org.apache.hadoop.hbase.client.Hbck
Like Admin.assign(byte[]) but 'raw' in that it can do more than one Region at a time -- good if many Regions to online -- and it will schedule the assigns even in the case where Master is initializing (as long as the ProcedureExecutor is up).
assigns(RpcController, MasterProtos.AssignsRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
A 'raw' version of assign that does bulk and can skirt Master state checks if override is set; i.e.
asSize() - Method in class org.apache.hadoop.hbase.hbtop.field.FieldValue
 
asString() - Method in class org.apache.hadoop.hbase.hbtop.field.FieldValue
 
asSubByteBuffer(int) - Method in class org.apache.hadoop.hbase.nio.ByteBuff
Returns bytes from current position till length specified, as a single ByteBuffer.
asSubByteBuffer(int) - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
Returns bytes from current position till length specified, as a single ByteBuffer.
asSubByteBuffer(int) - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
 
asSubByteBuffer(int, int, ObjectIntPair<ByteBuffer>) - Method in class org.apache.hadoop.hbase.nio.ByteBuff
Returns bytes from given offset till length specified, as a single ByteBuffer.
asSubByteBuffer(int, int, ObjectIntPair<ByteBuffer>) - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
Returns bytes from given offset till length specified, as a single ByteBuffer.
asSubByteBuffer(int, int, ObjectIntPair<ByteBuffer>) - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
 
asSubByteBuffers(long, int) - Method in class org.apache.hadoop.hbase.util.ByteBufferArray
Creates a sub-array from a given array of ByteBuffers from the given offset to the length specified.
ASYNC_DFS_OUTPUT_CREATE_MAX_RETRIES - Static variable in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputHelper
 
ASYNC_WAL - Enum constant in enum org.apache.hadoop.hbase.client.Durability
Write the Mutation to the WAL asynchronously
ASYNC_WAL_USE_SHARED_EVENT_LOOP - Static variable in class org.apache.hadoop.hbase.regionserver.wal.AsyncFSWAL
 
ASYNC_WAL_WAIT_ON_SHUTDOWN_IN_SECONDS - Static variable in class org.apache.hadoop.hbase.regionserver.wal.AsyncFSWAL
 
org.apache.hadoop.hbase.client.AsyncAdmin - Interface in org.apache.hadoop.hbase.client
The asynchronous administrative API for HBase.
org.apache.hadoop.hbase.client.AsyncAdminBuilder - Interface in org.apache.hadoop.hbase.client
For creating AsyncAdmin.
org.apache.hadoop.hbase.client.AsyncAdminClientUtils - Class in org.apache.hadoop.hbase.client
Additional Asynchronous Admin capabilities for clients.
org.apache.hadoop.hbase.client.AsyncAdminRequestRetryingCaller<T> - Class in org.apache.hadoop.hbase.client
 
AsyncAdminRequestRetryingCaller(Timer, AsyncConnectionImpl, int, long, long, int, long, long, int, ServerName, AsyncAdminRequestRetryingCaller.Callable<T>) - Constructor for class org.apache.hadoop.hbase.client.AsyncAdminRequestRetryingCaller
 
org.apache.hadoop.hbase.client.AsyncAdminRequestRetryingCaller.Callable<T> - Interface in org.apache.hadoop.hbase.client
 
org.apache.hadoop.hbase.client.AsyncBufferedMutator - Interface in org.apache.hadoop.hbase.client
Used to communicate with a single HBase table in batches.
org.apache.hadoop.hbase.client.AsyncBufferedMutatorBuilder - Interface in org.apache.hadoop.hbase.client
For creating AsyncBufferedMutator.
org.apache.hadoop.hbase.client.example.AsyncClientExample - Class in org.apache.hadoop.hbase.client.example
A simple example shows how to use asynchronous client.
AsyncClientExample() - Constructor for class org.apache.hadoop.hbase.client.example.AsyncClientExample
 
org.apache.hadoop.hbase.client.AsyncConnection - Interface in org.apache.hadoop.hbase.client
The asynchronous version of Connection.
org.apache.hadoop.hbase.client.AsyncConnectionImpl - Class in org.apache.hadoop.hbase.client
The implementation of AsyncConnection.
AsyncConnectionImpl(Configuration, ConnectionRegistry, String, User) - Constructor for class org.apache.hadoop.hbase.client.AsyncConnectionImpl
 
AsyncConnectionImpl(Configuration, ConnectionRegistry, String, User, Map<String, byte[]>) - Constructor for class org.apache.hadoop.hbase.client.AsyncConnectionImpl
 
asyncCreate(ZKWatcher, String, byte[], AsyncCallback.StringCallback, Object) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Async creates the specified node with the specified data.
org.apache.hadoop.hbase.io.asyncfs.AsyncFSOutput - Interface in org.apache.hadoop.hbase.io.asyncfs
Interface for asynchronous filesystem output stream.
org.apache.hadoop.hbase.io.asyncfs.AsyncFSOutputHelper - Class in org.apache.hadoop.hbase.io.asyncfs
Helper class for creating AsyncFSOutput.
org.apache.hadoop.hbase.regionserver.wal.AsyncFSWAL - Class in org.apache.hadoop.hbase.regionserver.wal
An asynchronous implementation of FSWAL.
AsyncFSWAL(FileSystem, Path, String, String, Configuration, List<WALActionsListener>, boolean, String, String, EventLoopGroup, Class<? extends Channel>) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.AsyncFSWAL
 
AsyncFSWAL(FileSystem, Abortable, Path, String, String, Configuration, List<WALActionsListener>, boolean, String, String, EventLoopGroup, Class<? extends Channel>, StreamSlowMonitor) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.AsyncFSWAL
 
org.apache.hadoop.hbase.wal.AsyncFSWALProvider - Class in org.apache.hadoop.hbase.wal
A WAL provider that use AsyncFSWAL.
AsyncFSWALProvider() - Constructor for class org.apache.hadoop.hbase.wal.AsyncFSWALProvider
 
org.apache.hadoop.hbase.wal.AsyncFSWALProvider.AsyncWriter - Interface in org.apache.hadoop.hbase.wal
 
org.apache.hadoop.hbase.client.AsyncMasterRequestRpcRetryingCaller<T> - Class in org.apache.hadoop.hbase.client
Retry caller for a request call to master.
AsyncMasterRequestRpcRetryingCaller(Timer, AsyncConnectionImpl, AsyncMasterRequestRpcRetryingCaller.Callable<T>, int, long, long, int, long, long, int) - Constructor for class org.apache.hadoop.hbase.client.AsyncMasterRequestRpcRetryingCaller
 
org.apache.hadoop.hbase.client.AsyncMasterRequestRpcRetryingCaller.Callable<T> - Interface in org.apache.hadoop.hbase.client
 
org.apache.hadoop.hbase.AsyncMetaTableAccessor - Class in org.apache.hadoop.hbase
The asynchronous meta table accessor.
AsyncMetaTableAccessor() - Constructor for class org.apache.hadoop.hbase.AsyncMetaTableAccessor
 
org.apache.hadoop.hbase.client.AsyncProcessTask<T> - Class in org.apache.hadoop.hbase.client
Contains the attributes of a task which will be executed by AsyncProcess.
org.apache.hadoop.hbase.client.AsyncProcessTask.Builder<T> - Class in org.apache.hadoop.hbase.client
 
org.apache.hadoop.hbase.client.AsyncProcessTask.SubmittedRows - Enum in org.apache.hadoop.hbase.client
The number of processed rows.
org.apache.hadoop.hbase.regionserver.wal.AsyncProtobufLogWriter - Class in org.apache.hadoop.hbase.regionserver.wal
AsyncWriter for protobuf-based WAL.
AsyncProtobufLogWriter(EventLoopGroup, Class<? extends Channel>) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.AsyncProtobufLogWriter
 
org.apache.hadoop.hbase.client.AsyncRequestFuture - Interface in org.apache.hadoop.hbase.client
The context used to wait for results from one submit call.
org.apache.hadoop.hbase.client.AsyncRpcRetryingCaller<T> - Class in org.apache.hadoop.hbase.client
 
AsyncRpcRetryingCaller(Timer, AsyncConnectionImpl, int, long, long, int, long, long, int, Map<String, byte[]>) - Constructor for class org.apache.hadoop.hbase.client.AsyncRpcRetryingCaller
 
org.apache.hadoop.hbase.client.AsyncServerRequestRpcRetryingCaller<T> - Class in org.apache.hadoop.hbase.client
Retry caller for a request call to region server.
AsyncServerRequestRpcRetryingCaller(Timer, AsyncConnectionImpl, long, long, int, long, long, int, ServerName, AsyncServerRequestRpcRetryingCaller.Callable<T>) - Constructor for class org.apache.hadoop.hbase.client.AsyncServerRequestRpcRetryingCaller
 
org.apache.hadoop.hbase.client.AsyncServerRequestRpcRetryingCaller.Callable<T> - Interface in org.apache.hadoop.hbase.client
 
org.apache.hadoop.hbase.client.AsyncTable<C extends org.apache.hadoop.hbase.client.ScanResultConsumerBase> - Interface in org.apache.hadoop.hbase.client
The interface for asynchronous version of Table.
org.apache.hadoop.hbase.client.AsyncTable.CheckAndMutateBuilder - Interface in org.apache.hadoop.hbase.client
Deprecated.
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 - Interface in org.apache.hadoop.hbase.client
Deprecated.
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.CoprocessorCallback<R> - Interface in org.apache.hadoop.hbase.client
The callback when we want to execute a coprocessor call on a range of regions.
org.apache.hadoop.hbase.client.AsyncTable.CoprocessorServiceBuilder<S,R> - Interface in org.apache.hadoop.hbase.client
Helper class for sending coprocessorService request that executes a coprocessor call on regions which are covered by a range.
org.apache.hadoop.hbase.client.AsyncTableBuilder<C extends org.apache.hadoop.hbase.client.ScanResultConsumerBase> - Interface in org.apache.hadoop.hbase.client
For creating AsyncTable.
org.apache.hadoop.hbase.client.AsyncTableRegionLocator - Interface in org.apache.hadoop.hbase.client
The asynchronous version of RegionLocator.
at(long) - Static method in class org.apache.hadoop.hbase.io.TimeRange
 
AT_LEAST_ONE - Enum constant in enum org.apache.hadoop.hbase.client.AsyncProcessTask.SubmittedRows
 
atHeadOfRingBufferEventHandlerAppend() - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
Exposed for testing only.
ATOMIC_BOOLEAN - Static variable in class org.apache.hadoop.hbase.util.ClassSize
Overhead for AtomicBoolean
ATOMIC_INTEGER - Static variable in class org.apache.hadoop.hbase.util.ClassSize
Overhead for AtomicInteger
ATOMIC_LONG - Static variable in class org.apache.hadoop.hbase.util.ClassSize
Overhead for AtomicLong
ATOMIC_REFERENCE - Static variable in class org.apache.hadoop.hbase.util.ClassSize
Overhead for AtomicReference
atomicIncrement(ByteBuffer, ByteBuffer, byte[], byte[], long) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
 
atomicIncrement(ByteBuffer, ByteBuffer, ByteBuffer, long) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
 
org.apache.hadoop.hbase.util.AtomicUtils - Class in org.apache.hadoop.hbase.util
Utilities related to atomic operations.
attemptToOwnTask(boolean, ZKWatcher, ServerName, String, int) - Static method in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination
Try to own the task by transitioning the zk node data from UNASSIGNED to OWNED.
ATTRIBUTE_SEPERATOR_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv
 
org.apache.hadoop.hbase.hbtop.terminal.Attributes - Class in org.apache.hadoop.hbase.hbtop.terminal
The attributes of text in the terminal.
org.apache.hadoop.hbase.client.Attributes - Interface in org.apache.hadoop.hbase.client
 
Attributes() - Constructor for class org.apache.hadoop.hbase.hbtop.terminal.Attributes
 
Attributes(Attributes) - Constructor for class org.apache.hadoop.hbase.hbtop.terminal.Attributes
 
ATTRIBUTES_COLUMN_SPEC - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
 
AUDITLOG - Static variable in class org.apache.hadoop.hbase.ipc.RpcServer
 
AUTH_FAILED_FOR - Static variable in class org.apache.hadoop.hbase.ipc.RpcServer
 
AUTH_SUCCESSFUL_FOR - Static variable in class org.apache.hadoop.hbase.ipc.RpcServer
 
AUTHENTICATION - Enum constant in enum org.apache.hadoop.hbase.security.SaslUtil.QualityOfProtection
 
AUTHENTICATION - Static variable in class org.apache.hadoop.hbase.HBaseInterfaceAudience
Denotes classes that can be used to build custom authentication solutions.
AUTHENTICATION_FAILURES_DESC - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
AUTHENTICATION_FAILURES_NAME - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
AUTHENTICATION_FALLBACKS_DESC - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
AUTHENTICATION_FALLBACKS_NAME - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
AUTHENTICATION_SUCCESSES_DESC - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
AUTHENTICATION_SUCCESSES_NAME - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
authenticationEnabled - Variable in class org.apache.hadoop.hbase.http.HttpServer
 
authenticationFailure() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
authenticationFailure() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceImpl
 
authenticationFallback() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
authenticationFallback() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceImpl
 
authenticationMethod - Variable in enum org.apache.hadoop.hbase.security.AuthMethod
 
authenticationSuccess() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
authenticationSuccess() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceImpl
 
authManager - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
 
org.apache.hadoop.hbase.security.AuthMethod - Enum in org.apache.hadoop.hbase.security
Authentication method
AUTHORIZATION - Enum constant in enum org.apache.hadoop.hbase.client.security.SecurityCapability
 
AUTHORIZATION_FAILURES_DESC - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
AUTHORIZATION_FAILURES_NAME - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
AUTHORIZATION_SUCCESSES_DESC - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
AUTHORIZATION_SUCCESSES_NAME - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
authorizationFailure() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
authorizationFailure() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceImpl
 
authorizationSuccess() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
authorizationSuccess() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceImpl
 
authorize(UserGroupInformation, RPCProtos.ConnectionHeader, InetAddress) - Method in class org.apache.hadoop.hbase.ipc.RpcServer
Authorize the incoming client connection.
authTokenSecretMgr - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
 
org.apache.hadoop.hbase.AuthUtil - Class in org.apache.hadoop.hbase
Deprecated.
since 2.2.0, to be marked as InterfaceAudience.Private in 4.0.0.
available() - Method in class org.apache.hadoop.hbase.io.ByteBufferInputStream
 
available() - Method in class org.apache.hadoop.hbase.io.ByteBuffInputStream
 
available() - Method in class org.apache.hadoop.hbase.io.FileLink.FileLinkInputStream
 
available(Configuration) - Static method in class org.apache.hadoop.hbase.client.HBaseAdmin
Is HBase available? Throw an exception if not.
AVERAGE_LOAD_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
 
AVERAGE_LOAD_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
 
AVERAGE_REGION_SIZE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
AVERAGE_REGION_SIZE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
org.apache.hadoop.hbase.quotas.AverageIntervalRateLimiter - Class in org.apache.hadoop.hbase.quotas
This limiter will refill resources at every TimeUnit/resources interval.
AverageIntervalRateLimiter() - Constructor for class org.apache.hadoop.hbase.quotas.AverageIntervalRateLimiter
 
AVG_STORE_FILE_AGE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
AVG_STORE_FILE_AGE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
avlHeight - Variable in class org.apache.hadoop.hbase.util.AvlUtil.AvlNode
 
AvlIterableList() - Constructor for class org.apache.hadoop.hbase.util.AvlUtil.AvlIterableList
 
avlLeft - Variable in class org.apache.hadoop.hbase.util.AvlUtil.AvlNode
 
AvlLinkedNode() - Constructor for class org.apache.hadoop.hbase.util.AvlUtil.AvlLinkedNode
 
AvlNode() - Constructor for class org.apache.hadoop.hbase.util.AvlUtil.AvlNode
 
avlRight - Variable in class org.apache.hadoop.hbase.util.AvlUtil.AvlNode
 
AvlTree() - Constructor for class org.apache.hadoop.hbase.util.AvlUtil.AvlTree
 
AvlTreeIterator() - Constructor for class org.apache.hadoop.hbase.util.AvlUtil.AvlTreeIterator
 
AvlTreeIterator(TNode) - Constructor for class org.apache.hadoop.hbase.util.AvlUtil.AvlTreeIterator
Create the iterator starting from the first (min) node of the tree
AvlTreeIterator(TNode, Object, AvlUtil.AvlKeyComparator<TNode>) - Constructor for class org.apache.hadoop.hbase.util.AvlUtil.AvlTreeIterator
Create the iterator starting from the specified key
org.apache.hadoop.hbase.util.AvlUtil - Class in org.apache.hadoop.hbase.util
Helper class that allows to create and manipulate an AvlTree.
org.apache.hadoop.hbase.util.AvlUtil.AvlInsertOrReplace<TNode extends org.apache.hadoop.hbase.util.AvlUtil.AvlNode> - Interface in org.apache.hadoop.hbase.util
 
org.apache.hadoop.hbase.util.AvlUtil.AvlIterableList - Class in org.apache.hadoop.hbase.util
Helper class that allows to create and manipulate a linked list of AvlLinkedNodes
org.apache.hadoop.hbase.util.AvlUtil.AvlKeyComparator<TNode extends org.apache.hadoop.hbase.util.AvlUtil.AvlNode> - Interface in org.apache.hadoop.hbase.util
The AvlTree allows to lookup an object using a custom key.
org.apache.hadoop.hbase.util.AvlUtil.AvlLinkedNode<TNode extends org.apache.hadoop.hbase.util.AvlUtil.AvlLinkedNode> - Class in org.apache.hadoop.hbase.util
This class extends the AvlNode and adds two links that will be used in conjunction with the AvlIterableList class.
org.apache.hadoop.hbase.util.AvlUtil.AvlNode<TNode extends org.apache.hadoop.hbase.util.AvlUtil.AvlNode> - Class in org.apache.hadoop.hbase.util
This class represent a node that will be used in an AvlTree.
org.apache.hadoop.hbase.util.AvlUtil.AvlNodeVisitor<TNode extends org.apache.hadoop.hbase.util.AvlUtil.AvlNode> - Interface in org.apache.hadoop.hbase.util
Visitor that allows to traverse a set of AvlNodes.
org.apache.hadoop.hbase.util.AvlUtil.AvlTree - Class in org.apache.hadoop.hbase.util
Helper class that allows to create and manipulate an AVL Tree
org.apache.hadoop.hbase.util.AvlUtil.AvlTreeIterator<TNode extends org.apache.hadoop.hbase.util.AvlUtil.AvlNode> - Class in org.apache.hadoop.hbase.util
Iterator for the AvlTree
await() - Method in class org.apache.hadoop.hbase.client.locking.EntityLock
 
await() - Method in class org.apache.hadoop.hbase.regionserver.MultiVersionConcurrencyControl
Wait until the read point catches up to the write point; i.e.
await(long, TimeUnit) - Method in class org.apache.hadoop.hbase.client.locking.EntityLock
 
awaitRunning() - Method in interface org.apache.hadoop.hbase.replication.ReplicationEndpoint
Waits for the ReplicationEndpoint to be up and running.
awaitRunning(long, TimeUnit) - Method in interface org.apache.hadoop.hbase.replication.ReplicationEndpoint
Waits for the ReplicationEndpoint to to be up and running for no more than the given time.
awaitTerminated() - Method in interface org.apache.hadoop.hbase.replication.ReplicationEndpoint
Waits for the ReplicationEndpoint to reach the terminated (internal) state.
awaitTerminated(long, TimeUnit) - Method in interface org.apache.hadoop.hbase.replication.ReplicationEndpoint
Waits for the ReplicationEndpoint to reach a terminal state for no more than the given time.

B

BACK_REFERENCES_DIRECTORY_PREFIX - Static variable in class org.apache.hadoop.hbase.io.FileLink
Define the Back-reference directory name prefix: .links-<hfile>/
BACKLOG_CONF_DEAFULT - Static variable in class org.apache.hadoop.hbase.thrift.Constants
 
BACKLOG_CONF_KEY - Static variable in class org.apache.hadoop.hbase.thrift.Constants
 
BACKOFF_POLICY_CLASS - Static variable in interface org.apache.hadoop.hbase.client.backoff.ClientBackoffPolicy
 
BackoffPolicy() - Constructor for class org.apache.hadoop.hbase.util.RetryCounter.BackoffPolicy
 
BACKSLASH - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for Backslash
backspace() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.InputModeScreenPresenter
 
Backspace - Enum constant in enum org.apache.hadoop.hbase.hbtop.terminal.KeyPress.Type
 
BACKUP_ATTEMPTS_PAUSE_MS_KEY - Static variable in interface org.apache.hadoop.hbase.backup.BackupRestoreConstants
 
BACKUP_CONFIG_STRING - Static variable in interface org.apache.hadoop.hbase.backup.BackupRestoreConstants
 
BACKUP_ENABLE_DEFAULT - Static variable in interface org.apache.hadoop.hbase.backup.BackupRestoreConstants
 
BACKUP_ENABLE_KEY - Static variable in interface org.apache.hadoop.hbase.backup.BackupRestoreConstants
 
BACKUP_MASTERS - Enum constant in enum org.apache.hadoop.hbase.ClusterMetrics.Option
metrics about backup masters name
BACKUP_MAX_ATTEMPTS_KEY - Static variable in interface org.apache.hadoop.hbase.backup.BackupRestoreConstants
 
BACKUP_SYSTEM_TABLE_NAME_DEFAULT - Static variable in interface org.apache.hadoop.hbase.backup.BackupRestoreConstants
 
BACKUP_SYSTEM_TABLE_NAME_KEY - Static variable in interface org.apache.hadoop.hbase.backup.BackupRestoreConstants
 
BACKUP_SYSTEM_TTL_DEFAULT - Static variable in interface org.apache.hadoop.hbase.backup.BackupRestoreConstants
 
BACKUP_SYSTEM_TTL_KEY - Static variable in interface org.apache.hadoop.hbase.backup.BackupRestoreConstants
 
org.apache.hadoop.hbase.backup.BackupAdmin - Interface in org.apache.hadoop.hbase.backup
The administrative API for HBase Backup.
org.apache.hadoop.hbase.backup.BackupClientFactory - Class in org.apache.hadoop.hbase.backup
 
org.apache.hadoop.hbase.backup.BackupCopyJob - Interface in org.apache.hadoop.hbase.backup
Backup copy job is a part of a backup process.
org.apache.hadoop.hbase.backup.BackupDriver - Class in org.apache.hadoop.hbase.backup
Command-line entry point for backup operation
BackupDriver() - Constructor for class org.apache.hadoop.hbase.backup.BackupDriver
 
org.apache.hadoop.hbase.backup.BackupHFileCleaner - Class in org.apache.hadoop.hbase.backup
Implementation of a file cleaner that checks if an hfile is still referenced by backup before deleting it from hfile archive directory.
BackupHFileCleaner() - Constructor for class org.apache.hadoop.hbase.backup.BackupHFileCleaner
 
BACKUPID_PREFIX - Static variable in interface org.apache.hadoop.hbase.backup.BackupRestoreConstants
 
org.apache.hadoop.hbase.backup.BackupInfo - Class in org.apache.hadoop.hbase.backup
An object to encapsulate the information for each backup session
BackupInfo() - Constructor for class org.apache.hadoop.hbase.backup.BackupInfo
 
BackupInfo(String, BackupType, TableName[], String) - Constructor for class org.apache.hadoop.hbase.backup.BackupInfo
 
org.apache.hadoop.hbase.backup.BackupInfo.BackupPhase - Enum in org.apache.hadoop.hbase.backup
BackupPhase - phases of an ACTIVE backup session (running), when state of a backup session is BackupState.RUNNING
org.apache.hadoop.hbase.backup.BackupInfo.BackupState - Enum in org.apache.hadoop.hbase.backup
Backup session states
org.apache.hadoop.hbase.backup.BackupInfo.Filter - Interface in org.apache.hadoop.hbase.backup
 
backupMasterAddressesZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZNodePaths
 
org.apache.hadoop.hbase.backup.BackupMergeJob - Interface in org.apache.hadoop.hbase.backup
Backup merge operation job interface.
org.apache.hadoop.hbase.backup.BackupObserver - Class in org.apache.hadoop.hbase.backup
An Observer to facilitate backup operations
BackupObserver() - Constructor for class org.apache.hadoop.hbase.backup.BackupObserver
 
org.apache.hadoop.hbase.backup.BackupRequest - Class in org.apache.hadoop.hbase.backup
POJO class for backup request
org.apache.hadoop.hbase.backup.BackupRequest.Builder - Class in org.apache.hadoop.hbase.backup
 
org.apache.hadoop.hbase.backup.BackupRestoreConstants - Interface in org.apache.hadoop.hbase.backup
BackupRestoreConstants holds a bunch of HBase Backup and Restore constants
org.apache.hadoop.hbase.backup.BackupRestoreConstants.BackupCommand - Enum in org.apache.hadoop.hbase.backup
 
org.apache.hadoop.hbase.backup.BackupRestoreFactory - Class in org.apache.hadoop.hbase.backup
Factory implementation for backup/restore related jobs
org.apache.hadoop.hbase.backup.BackupTableInfo - Class in org.apache.hadoop.hbase.backup
Backup related information encapsulated for a table.
BackupTableInfo() - Constructor for class org.apache.hadoop.hbase.backup.BackupTableInfo
 
BackupTableInfo(TableName, String, String) - Constructor for class org.apache.hadoop.hbase.backup.BackupTableInfo
 
backupTables(BackupRequest) - Method in interface org.apache.hadoop.hbase.backup.BackupAdmin
Backup given list of tables fully.
org.apache.hadoop.hbase.backup.BackupType - Enum in org.apache.hadoop.hbase.backup
 
backwardSeek(Cell) - Method in interface org.apache.hadoop.hbase.regionserver.KeyValueScanner
Seek the scanner at or before the row of specified Cell, it firstly tries to seek the scanner at or after the specified Cell, return if peek KeyValue of scanner has the same row with specified Cell, otherwise seek the scanner at the first Cell of the row which is the previous row of specified KeyValue
backwardSeek(Cell) - Method in class org.apache.hadoop.hbase.regionserver.NonReversedNonLazyKeyValueScanner
 
backwardSeek(Cell) - Method in class org.apache.hadoop.hbase.regionserver.ReversedKeyValueHeap
 
backwardSeek(Cell) - Method in class org.apache.hadoop.hbase.regionserver.ReversedStoreScanner
 
backwardSeek(Cell) - Method in class org.apache.hadoop.hbase.regionserver.SegmentScanner
Seek the scanner at or before the row of specified Cell, it firstly tries to seek the scanner at or after the specified Cell, return if peek KeyValue of scanner has the same row with specified Cell, otherwise seek the scanner at the first Cell of the row which is the previous row of specified KeyValue
backwardSeek(Cell) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
 
BAD_FAMILY - Enum constant in enum org.apache.hadoop.hbase.HConstants.OperationStatusCode
 
org.apache.hadoop.hbase.ipc.BadAuthException - Exception in org.apache.hadoop.hbase.ipc
 
BadAuthException() - Constructor for exception org.apache.hadoop.hbase.ipc.BadAuthException
 
BadAuthException(String) - Constructor for exception org.apache.hadoop.hbase.ipc.BadAuthException
 
BadAuthException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.ipc.BadAuthException
 
BadFormatException(String) - Constructor for exception org.apache.hadoop.hbase.http.conf.ConfServlet.BadFormatException
 
BadTsvLineException(String) - Constructor for exception org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser.BadTsvLineException
 
balance() - Method in interface org.apache.hadoop.hbase.client.Admin
Invoke the balancer.
balance() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Invoke the balancer.
balance() - Method in class org.apache.hadoop.hbase.master.HMaster
 
balance(boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
Since 2.5.0. Will be removed in 4.0.0. Use Admin.balance(BalanceRequest) instead.
balance(boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Deprecated.
Since 2.5.0. Will be removed in 4.0.0. Use AsyncAdmin.balance(BalanceRequest) instead.
balance(BalanceRequest) - Method in interface org.apache.hadoop.hbase.client.Admin
Invoke the balancer with the given balance request.
balance(BalanceRequest) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Invoke the balancer with the given balance request.
balance(BalanceRequest) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
balance(BalanceRequest) - Method in class org.apache.hadoop.hbase.master.HMaster
 
balance(RpcController, MasterProtos.BalanceRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
balance(RpcController, MasterProtos.BalanceRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
 
BALANCE_DECISION - Enum constant in enum org.apache.hadoop.hbase.namequeues.NamedQueuePayload.NamedQueueEvent
 
BALANCE_REJECTION - Enum constant in enum org.apache.hadoop.hbase.namequeues.NamedQueuePayload.NamedQueueEvent
 
balanceCluster(Map<TableName, Map<ServerName, List<RegionInfo>>>) - Method in interface org.apache.hadoop.hbase.master.LoadBalancer
Perform the major balance operation for cluster.
balanceCluster(Map<TableName, Map<ServerName, List<RegionInfo>>>) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupBasedLoadBalancer
Balance by RSGroup.
org.apache.hadoop.hbase.ipc.BalancedQueueRpcExecutor - Class in org.apache.hadoop.hbase.ipc
An RpcExecutor that will balance requests evenly across all its queues, but still remains efficient with a single queue via an inlinable queue balancing mechanism.
BalancedQueueRpcExecutor(String, int, int, PriorityFunction, Configuration, Abortable) - Constructor for class org.apache.hadoop.hbase.ipc.BalancedQueueRpcExecutor
 
BalancedQueueRpcExecutor(String, int, String, int, PriorityFunction, Configuration, Abortable) - Constructor for class org.apache.hadoop.hbase.ipc.BalancedQueueRpcExecutor
 
balanceOrUpdateMetrics() - Method in class org.apache.hadoop.hbase.master.HMaster
Trigger a normal balance, see HMaster.balance() .
balancer() - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
Since 2.0.0. Will be removed in 3.0.0. Use Admin.balance() instead.
balancer(boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
Since 2.0.0. Will be removed in 3.0.0. Use Admin.balance(BalanceRequest) instead.
BALANCER_DECISION_EVENT - Static variable in class org.apache.hadoop.hbase.namequeues.BalancerDecisionDetails
 
BALANCER_ON - Enum constant in enum org.apache.hadoop.hbase.ClusterMetrics.Option
metrics about balancer is on or not
BALANCER_REJECTION_EVENT - Static variable in class org.apache.hadoop.hbase.namequeues.BalancerRejectionDetails
 
BalancerDecision - Class in org.apache.hadoop.hbase.client
History of balancer decisions taken for region movements.
org.apache.hadoop.hbase.client.BalancerDecision.Builder - Class in org.apache.hadoop.hbase.client
 
org.apache.hadoop.hbase.namequeues.BalancerDecisionDetails - Class in org.apache.hadoop.hbase.namequeues
Balancer decision details that would be passed on to ring buffer for history
BalancerDecisionDetails(BalancerDecision) - Constructor for class org.apache.hadoop.hbase.namequeues.BalancerDecisionDetails
 
org.apache.hadoop.hbase.namequeues.impl.BalancerDecisionQueueService - Class in org.apache.hadoop.hbase.namequeues.impl
In-memory Queue service provider for Balancer Decision events
BalancerDecisionQueueService(Configuration) - Constructor for class org.apache.hadoop.hbase.namequeues.impl.BalancerDecisionQueueService
 
org.apache.hadoop.hbase.client.BalanceRequest - Class in org.apache.hadoop.hbase.client
Encapsulates options for executing a run of the Balancer.
org.apache.hadoop.hbase.client.BalanceRequest.Builder - Class in org.apache.hadoop.hbase.client
Builder for constructing a BalanceRequest
org.apache.hadoop.hbase.client.BalanceResponse - Class in org.apache.hadoop.hbase.client
Response returned from a balancer invocation
org.apache.hadoop.hbase.client.BalanceResponse.Builder - Class in org.apache.hadoop.hbase.client
Used in HMaster to build a BalanceResponse for returning results of a balance invocation to callers
BalancerRejection - Class in org.apache.hadoop.hbase.client
History of detail information that balancer movements was rejected
org.apache.hadoop.hbase.client.BalancerRejection.Builder - Class in org.apache.hadoop.hbase.client
 
org.apache.hadoop.hbase.namequeues.BalancerRejectionDetails - Class in org.apache.hadoop.hbase.namequeues
Balancer rejection details that would be passed on to ring buffer for history
BalancerRejectionDetails(BalancerRejection) - Constructor for class org.apache.hadoop.hbase.namequeues.BalancerRejectionDetails
 
org.apache.hadoop.hbase.namequeues.impl.BalancerRejectionQueueService - Class in org.apache.hadoop.hbase.namequeues.impl
In-memory Queue service provider for Balancer Rejection events
BalancerRejectionQueueService(Configuration) - Constructor for class org.apache.hadoop.hbase.namequeues.impl.BalancerRejectionQueueService
 
balanceRSGroup(String) - Method in interface org.apache.hadoop.hbase.rsgroup.RSGroupAdmin
Balance regions in the given RegionServer group.
balanceRSGroup(String, BalanceRequest) - Method in interface org.apache.hadoop.hbase.rsgroup.RSGroupAdmin
Balance regions in the given RegionServer group, running based on the given BalanceRequest.
balanceRSGroup(String, BalanceRequest) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminClient
 
balanceRSGroup(String, BalanceRequest) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminServer
 
balancerSwitch(boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Turn the load balancer on or off.
balancerSwitch(boolean, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
Turn the load balancer on or off.
balancerSwitch(boolean, boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Turn the load balancer on or off.
balancerSwitch(boolean, boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
balancerZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZNodePaths
Deprecated.
Since 2.6.0, will be removed in 4.0.0. We use master local region to store this state.
balanceSwitch(boolean) - Method in class org.apache.hadoop.hbase.master.HMaster
 
balanceTable(TableName, Map<ServerName, List<RegionInfo>>) - Method in class org.apache.hadoop.hbase.favored.FavoredNodeLoadBalancer
 
base - Variable in class org.apache.hadoop.hbase.types.FixedLengthWrapper
 
BASE_NAMESPACE_DIR - Static variable in class org.apache.hadoop.hbase.HConstants
 
org.apache.hadoop.hbase.BaseConfigurable - Class in org.apache.hadoop.hbase
HBase version of Hadoop's Configured class that doesn't initialize the configuration via BaseConfigurable.setConf(Configuration) in the constructor, but only sets the configuration through the BaseConfigurable.setConf(Configuration) method
BaseConfigurable() - Constructor for class org.apache.hadoop.hbase.BaseConfigurable
 
org.apache.hadoop.hbase.codec.BaseDecoder - Class in org.apache.hadoop.hbase.codec
TODO javadoc
BaseDecoder(InputStream) - Constructor for class org.apache.hadoop.hbase.codec.BaseDecoder
 
org.apache.hadoop.hbase.codec.BaseDecoder.PBIS - Class in org.apache.hadoop.hbase.codec
 
org.apache.hadoop.hbase.codec.BaseEncoder - Class in org.apache.hadoop.hbase.codec
TODO javadoc
BaseEncoder(OutputStream) - Constructor for class org.apache.hadoop.hbase.codec.BaseEncoder
 
org.apache.hadoop.hbase.coprocessor.BaseEnvironment<C extends org.apache.hadoop.hbase.Coprocessor> - Class in org.apache.hadoop.hbase.coprocessor
Encapsulation of the environment of each coprocessor
BaseEnvironment(C, int, int, Configuration) - Constructor for class org.apache.hadoop.hbase.coprocessor.BaseEnvironment
Constructor
org.apache.hadoop.hbase.replication.BaseReplicationEndpoint - Class in org.apache.hadoop.hbase.replication
A Base implementation for ReplicationEndpoints.
BaseReplicationEndpoint() - Constructor for class org.apache.hadoop.hbase.replication.BaseReplicationEndpoint
 
org.apache.hadoop.hbase.regionserver.BaseRowProcessor<S extends com.google.protobuf.Message,T extends com.google.protobuf.Message> - Class in org.apache.hadoop.hbase.regionserver
Base class for RowProcessor with some default implementations.
BaseRowProcessor() - Constructor for class org.apache.hadoop.hbase.regionserver.BaseRowProcessor
 
org.apache.hadoop.hbase.coprocessor.BaseRowProcessorEndpoint<S extends com.google.protobuf.Message,T extends com.google.protobuf.Message> - Class in org.apache.hadoop.hbase.coprocessor
This class demonstrates how to implement atomic read-modify-writes using Region.processRowsWithLocks(org.apache.hadoop.hbase.regionserver.RowProcessor<?, ?>) and Coprocessor endpoints.
BaseRowProcessorEndpoint() - Constructor for class org.apache.hadoop.hbase.coprocessor.BaseRowProcessorEndpoint
 
org.apache.hadoop.hbase.metrics.BaseSource - Interface in org.apache.hadoop.hbase.metrics
BaseSource for dynamic metrics to announce to Metrics2.
org.apache.hadoop.hbase.metrics.BaseSourceImpl - Class in org.apache.hadoop.hbase.metrics
Hadoop 2 implementation of BaseSource (using metrics2 framework).
BaseSourceImpl(String, String, String, String) - Constructor for class org.apache.hadoop.hbase.metrics.BaseSourceImpl
 
baseZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZNodePaths
 
BASIC - Enum constant in enum org.apache.hadoop.hbase.MemoryCompactionPolicy
Basic policy applies optimizations which modify the index to a more compacted representation.
org.apache.hadoop.hbase.regionserver.BasicMemStoreCompactionStrategy - Class in org.apache.hadoop.hbase.regionserver
Basic strategy chooses between two actions: flattening a segment or merging indices of all segments in the pipeline.
BasicMemStoreCompactionStrategy(Configuration, String) - Constructor for class org.apache.hadoop.hbase.regionserver.BasicMemStoreCompactionStrategy
 
batch - Variable in class org.apache.hadoop.hbase.master.SplitLogManager.Task
Deprecated.
 
batch(List<? extends Row>) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
Method that does a batch call on Deletes, Gets, Puts, Increments, Appends and RowMutations.
batch(List<? extends Row>, Object[]) - Method in class org.apache.hadoop.hbase.client.HTable
 
batch(List<? extends Row>, Object[]) - Method in interface org.apache.hadoop.hbase.client.Table
Method that does a batch call on Deletes, Gets, Puts, Increments, Appends, RowMutations.
batch(List<? extends Row>, Object[], int) - Method in class org.apache.hadoop.hbase.client.HTable
 
BATCH_GET_KEY - Static variable in interface org.apache.hadoop.hbase.thrift.MetricsThriftServerSource
 
BATCH_LIMIT_REACHED - Enum constant in enum org.apache.hadoop.hbase.regionserver.ScannerContext.NextState
 
BATCH_MUTATE - Enum constant in enum org.apache.hadoop.hbase.regionserver.Region.Operation
 
BATCH_MUTATE_KEY - Static variable in interface org.apache.hadoop.hbase.thrift.MetricsThriftServerSource
 
BATCH_ROWS_THRESHOLD_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
Default value of HConstants.BATCH_ROWS_THRESHOLD_NAME
BATCH_ROWS_THRESHOLD_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
Number of rows in a batch operation above which a warning will be logged.
batchAll(List<? extends Row>) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
A simple version of batch.
batchCallback(List<? extends Row>, Object[], Batch.Callback<R>) - Method in class org.apache.hadoop.hbase.client.HTable
 
batchCallback(List<? extends Row>, Object[], Batch.Callback<R>) - Method in interface org.apache.hadoop.hbase.client.Table
Same as Table.batch(List, Object[]), but with a callback.
batchCoprocessorService(Descriptors.MethodDescriptor, Message, byte[], byte[], R) - Method in class org.apache.hadoop.hbase.client.HTable
 
batchCoprocessorService(Descriptors.MethodDescriptor, Message, byte[], byte[], R) - Method in interface org.apache.hadoop.hbase.client.Table
Creates an instance of the given Service subclass for each table region spanning the range from the startKey row to endKey row (inclusive), all the invocations to the same region server will be batched into one call.
batchCoprocessorService(Descriptors.MethodDescriptor, Message, byte[], byte[], R, Batch.Callback<R>) - Method in class org.apache.hadoop.hbase.client.HTable
 
batchCoprocessorService(Descriptors.MethodDescriptor, Message, byte[], byte[], R, Batch.Callback<R>) - Method in interface org.apache.hadoop.hbase.client.Table
Creates an instance of the given Service subclass for each table region spanning the range from the startKey row to endKey row (inclusive), all the invocations to the same region server will be batched into one call.
BATCHES - Enum constant in enum org.apache.hadoop.hbase.mapreduce.SyncTable.SyncMapper.Counter
 
batchMutate(Mutation[]) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
batchMutate(Mutation[]) - Method in interface org.apache.hadoop.hbase.regionserver.Region
Perform a batch of mutations.
batchMutate(Mutation[], boolean, long, long) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
batchReplay(WALSplitUtil.MutationReplay[], long) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
org.apache.hadoop.hbase.client.BatchScanResultCache - Class in org.apache.hadoop.hbase.client
A scan result cache for batched scan, i.e, scan.getBatch() > 0 && !scan.getAllowPartialResults().
BatchScanResultCache(int) - Constructor for class org.apache.hadoop.hbase.client.BatchScanResultCache
 
org.apache.hadoop.hbase.hbtop.terminal.impl.batch.BatchTerminal - Class in org.apache.hadoop.hbase.hbtop.terminal.impl.batch
An implementation of the Terminal interface for batch mode.
BatchTerminal() - Constructor for class org.apache.hadoop.hbase.hbtop.terminal.impl.batch.BatchTerminal
 
org.apache.hadoop.hbase.hbtop.terminal.impl.batch.BatchTerminalPrinter - Class in org.apache.hadoop.hbase.hbtop.terminal.impl.batch
An implementation of the TerminalPrinter interface for batch mode.
BatchTerminalPrinter() - Constructor for class org.apache.hadoop.hbase.hbtop.terminal.impl.batch.BatchTerminalPrinter
 
bbAllocator - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
 
bbAllocator - Variable in class org.apache.hadoop.hbase.ipc.ServerCall
 
BCFKS - Enum constant in enum org.apache.hadoop.hbase.io.crypto.tls.KeyStoreFileType
 
beforeExecute(Thread, Runnable) - Method in class org.apache.hadoop.hbase.thrift.THBaseThreadPoolExecutor
 
beforeExecution() - Method in interface org.apache.hadoop.hbase.regionserver.FlushLifeCycleTracker
Called before flush is executed.
beforeShipped() - Method in class org.apache.hadoop.hbase.io.encoding.EncodingState
 
beforeShipped() - Method in class org.apache.hadoop.hbase.io.hfile.CompoundBloomFilterWriter
 
beforeShipped() - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterImpl
 
beforeShipped() - Method in class org.apache.hadoop.hbase.regionserver.AbstractMultiFileWriter
 
beforeShipped() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.CompactionScanQueryMatcher
 
beforeShipped() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ExplicitColumnTracker
 
beforeShipped() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.NewVersionBehaviorTracker
 
beforeShipped() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.NormalUserScanQueryMatcher
 
beforeShipped() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanDeleteTracker
 
beforeShipped() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher
 
beforeShipped() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanWildcardColumnTracker
 
beforeShipped() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.UserScanQueryMatcher
 
beforeShipped() - Method in interface org.apache.hadoop.hbase.regionserver.ShipperListener
The action that needs to be performed before Shipper.shipped() is performed
beforeShipped() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileWriter
 
beforeWaitOnSafePoint() - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
 
begin() - Method in class org.apache.hadoop.hbase.regionserver.MultiVersionConcurrencyControl
Call MultiVersionConcurrencyControl.begin(Runnable) with an empty Runnable.
begin(Runnable) - Method in class org.apache.hadoop.hbase.regionserver.MultiVersionConcurrencyControl
Start a write transaction.
beginPersistentOutput() - Method in class org.apache.hadoop.hbase.wal.WALPrettyPrinter
enables output as a single, persistent list.
between(long, long) - Static method in class org.apache.hadoop.hbase.io.TimeRange
Represents the time interval [minStamp, maxStamp)
BETWEEN_CELLS - Enum constant in enum org.apache.hadoop.hbase.regionserver.ScannerContext.LimitScope
Enforcing a limit between cells means that the limit will be considered after each full cell has been retrieved
BETWEEN_ROWS - Enum constant in enum org.apache.hadoop.hbase.regionserver.ScannerContext.LimitScope
Enforcing a limit between rows means that the limit will not be considered until all the cells for a particular row have been retrieved
org.apache.hadoop.hbase.filter.BigDecimalComparator - Class in org.apache.hadoop.hbase.filter
A BigDecimal comparator which numerical compares against the specified byte array
BigDecimalComparator(BigDecimal) - Constructor for class org.apache.hadoop.hbase.filter.BigDecimalComparator
 
org.apache.hadoop.hbase.filter.BinaryComparator - Class in org.apache.hadoop.hbase.filter
A binary comparator which lexicographically compares against the specified byte array using Bytes.compareTo(byte[], byte[]).
BinaryComparator(byte[]) - Constructor for class org.apache.hadoop.hbase.filter.BinaryComparator
Constructor
org.apache.hadoop.hbase.filter.BinaryComponentComparator - Class in org.apache.hadoop.hbase.filter
A comparator which compares against a specified byte array, but only compares specific portion of the byte array.
BinaryComponentComparator(byte[], int) - Constructor for class org.apache.hadoop.hbase.filter.BinaryComponentComparator
Constructor
org.apache.hadoop.hbase.filter.BinaryPrefixComparator - Class in org.apache.hadoop.hbase.filter
A comparator which compares against a specified byte array, but only compares up to the length of this byte array.
BinaryPrefixComparator(byte[]) - Constructor for class org.apache.hadoop.hbase.filter.BinaryPrefixComparator
Constructor
binaryPrefixType - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
BinaryPrefixType byte array
binarySearch(byte[][], byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Binary search for keys in indexes using Bytes.BYTES_RAWCOMPARATOR.
binarySearch(byte[][], byte[], int, int, RawComparator<?>) - Static method in class org.apache.hadoop.hbase.util.Bytes
Deprecated.
since 2.0.0 and will be removed in 3.0.0. Use Bytes.binarySearch(byte[][], byte[], int, int) instead.
binarySearch(byte[][], Cell, RawComparator<Cell>) - Static method in class org.apache.hadoop.hbase.util.Bytes
Deprecated.
since 2.0.0 and will be removed in 3.0.0. Use Bytes.binarySearch(Cell[], Cell, CellComparator) instead.
binarySearch(Cell[], byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Result
 
binarySearch(Cell[], byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.client.Result
Searches for the latest value for the specified column.
binarySearch(Cell[], Cell, CellComparator) - Static method in class org.apache.hadoop.hbase.util.Bytes
Binary search for keys in indexes.
binaryType - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
BinaryType byte array
bind(ServerSocket, InetSocketAddress, int) - Static method in class org.apache.hadoop.hbase.ipc.SimpleRpcServer
Deprecated.
A convenience method to bind to a given address and report better exceptions if the address is not a valid host.
BIND_ADDRESS - Static variable in class org.apache.hadoop.hbase.http.HttpServer
 
BIND_CONF_KEY - Static variable in class org.apache.hadoop.hbase.thrift.Constants
 
BIND_OPTION - Static variable in class org.apache.hadoop.hbase.thrift.Constants
 
bindAddress - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
 
org.apache.hadoop.hbase.filter.BitComparator - Class in org.apache.hadoop.hbase.filter
A bit comparator which performs the specified bitwise operation on each of the bytes with the specified byte array.
BitComparator(byte[], BitComparator.BitwiseOp) - Constructor for class org.apache.hadoop.hbase.filter.BitComparator
Constructor
org.apache.hadoop.hbase.filter.BitComparator.BitwiseOp - Enum in org.apache.hadoop.hbase.filter
Bit operators.
bitOperator - Variable in class org.apache.hadoop.hbase.filter.BitComparator
 
bitvals - Static variable in class org.apache.hadoop.hbase.util.BloomFilterUtil
Bit-value lookup array to prevent doing the same work over and over
BLACK - Enum constant in enum org.apache.hadoop.hbase.hbtop.terminal.Color
 
BlackListDirFilter(FileSystem, List<String>) - Constructor for class org.apache.hadoop.hbase.util.FSUtils.BlackListDirFilter
Create a filter on the givem filesystem with the specified blacklist
blobVarEncodedLength(int) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Calculate the expected BlobVar encoded length based on unencoded length.
BLOCK_BYTES_SCANNED_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_BYTES_SCANNED_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_BLOOM_CHUNK_HIT_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_BLOOM_CHUNK_MISS_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_DATA_BLOCK_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_DATA_BLOCK_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_DATA_HIT_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_DATA_MISS_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_DELETE_FAMILY_BLOOM_HIT_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_DELETE_FAMILY_BLOOM_MISS_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_ENCODED_DATA_HIT_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_ENCODED_DATA_MISS_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_EVICTION_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_EVICTION_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_EXPRESS_HIT_PERCENT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_EXPRESS_HIT_PERCENT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_FAILED_INSERTION_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_FAILED_INSERTION_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_FILE_INFO_HIT_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_FILE_INFO_MISS_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_FREE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_FREE_SIZE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_GENERAL_BLOOM_META_HIT_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_GENERAL_BLOOM_META_MISS_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_HIT_CACHING_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_HIT_CACHING_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_HIT_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_HIT_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_HIT_PERCENT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_HIT_PERCENT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_INTERMEDIATE_INDEX_HIT_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_INTERMEDIATE_INDEX_MISS_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_LEAF_INDEX_HIT_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_LEAF_INDEX_MISS_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_META_HIT_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_META_MISS_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_MISS_CACHING_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_MISS_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_PRIMARY_EVICTION_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_PRIMARY_EVICTION_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_PRIMARY_HIT_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_PRIMARY_HIT_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_PRIMARY_MISS_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_ROOT_INDEX_HIT_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_ROOT_INDEX_MISS_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_SIZE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_SIZE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_SIZE_MAX_RANGE_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager
 
BLOCK_CACHE_SIZE_MIN_RANGE_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager
 
BLOCK_CACHE_TRAILER_HIT_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_CACHE_TRAILER_MISS_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_COMPRESSED_SIZE_PREDICATOR - Static variable in interface org.apache.hadoop.hbase.io.hfile.BlockCompressedSizePredicator
 
BLOCK_COUNT_MISS_CACHING_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_COUNT_MISS_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_COUNT_PRIMARY_MISS_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCK_DESERIALIZER - Static variable in class org.apache.hadoop.hbase.io.hfile.HFileBlock
Used deserializing blocks from Cache.
BLOCK_METADATA_SPACE - Static variable in class org.apache.hadoop.hbase.io.hfile.HFileBlock
Space for metadata on a block that gets stored along with the block when we cache it.
BLOCK_SIZE - Static variable in class org.apache.hadoop.hbase.io.crypto.Cipher
 
BLOCK_STORAGE_POLICY_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.HStore
 
org.apache.hadoop.hbase.io.hfile.BlockCache - Interface in org.apache.hadoop.hbase.io.hfile
Block cache interface.
BLOCKCACHE - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
Key for the BLOCKCACHE attribute.
BLOCKCACHE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
BLOCKCACHE_BLOCKSIZE_KEY - Static variable in class org.apache.hadoop.hbase.io.hfile.BlockCacheFactory
The target block size used by blockcache instances.
BLOCKCACHE_POLICY_DEFAULT - Static variable in class org.apache.hadoop.hbase.io.hfile.BlockCacheFactory
 
BLOCKCACHE_POLICY_KEY - Static variable in class org.apache.hadoop.hbase.io.hfile.BlockCacheFactory
Configuration key to cache block policy (Lru, TinyLfu, AdaptiveLRU, IndexOnlyLRU).
BLOCKCACHE_SIZE_GAUGE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSource
 
BLOCKCACHE_SIZE_GAUGE_NAME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSource
 
org.apache.hadoop.hbase.io.hfile.BlockCacheFactory - Class in org.apache.hadoop.hbase.io.hfile
 
org.apache.hadoop.hbase.io.hfile.BlockCacheKey - Class in org.apache.hadoop.hbase.io.hfile
Cache Key for use with implementations of BlockCache
BlockCacheKey(String, long) - Constructor for class org.apache.hadoop.hbase.io.hfile.BlockCacheKey
Construct a new BlockCacheKey
BlockCacheKey(String, long, boolean, BlockType) - Constructor for class org.apache.hadoop.hbase.io.hfile.BlockCacheKey
 
org.apache.hadoop.hbase.io.hfile.BlockCacheUtil - Class in org.apache.hadoop.hbase.io.hfile
Utilty for aggregating counts in CachedBlocks and toString/toJSON CachedBlocks and BlockCaches.
BlockCacheUtil() - Constructor for class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil
 
org.apache.hadoop.hbase.io.hfile.BlockCacheUtil.CachedBlocksByFile - Class in org.apache.hadoop.hbase.io.hfile
Use one of these to keep a running account of cached blocks by file.
org.apache.hadoop.hbase.io.hfile.BlockCompressedSizePredicator - Interface in org.apache.hadoop.hbase.io.hfile
Allows for defining different compression rate predicates on its implementing classes.
blockDataSizes - Variable in class org.apache.hadoop.hbase.io.hfile.NoOpIndexBlockEncoder.NoOpEncodedSeeker
 
BLOCKED_FLUSH_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSource
 
BLOCKED_FLUSH_GAUGE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSource
 
BLOCKED_FLUSH_GAUGE_NAME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSource
 
BLOCKED_FLUSH_NAME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSource
 
BLOCKED_REQUESTS_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOCKED_REQUESTS_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
blockEncoder - Variable in class org.apache.hadoop.hbase.io.hfile.HFileWriterImpl
The data block encoding which will be used.
blockFitsIntoTheCache(HFileBlock) - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCache
Checks whether there's enough space left in the cache to accommodate the passed block.
blockFitsIntoTheCache(HFileBlock) - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
 
org.apache.hadoop.hbase.io.hfile.BlockIndexChunk - Interface in org.apache.hadoop.hbase.io.hfile
 
BlockIndexNotLoadedException(Path) - Constructor for exception org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.BlockIndexNotLoadedException
 
BlockIndexWriter() - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexWriter
Creates a single-level block index writer
BlockIndexWriter(HFileBlock.Writer, CacheConfig, String, HFileIndexBlockEncoder) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexWriter
Creates a multi-level block index writer.
BLOCKING_STOREFILES_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.HStore
 
org.apache.hadoop.hbase.ipc.BlockingRpcCallback<R> - Class in org.apache.hadoop.hbase.ipc
Simple RpcCallback implementation providing a Future-like BlockingRpcCallback.get() method, which will block util the instance's BlockingRpcCallback.run(Object) method has been called.
BlockingRpcCallback() - Constructor for class org.apache.hadoop.hbase.ipc.BlockingRpcCallback
 
BlockingRpcCallback() - Constructor for class org.apache.hadoop.hbase.ipc.CoprocessorRpcUtils.BlockingRpcCallback
 
BlockingRpcChannelImplementation(AbstractRpcClient<?>, Address, User, int) - Constructor for class org.apache.hadoop.hbase.ipc.AbstractRpcClient.BlockingRpcChannelImplementation
 
org.apache.hadoop.hbase.ipc.BlockingRpcClient - Class in org.apache.hadoop.hbase.ipc
Does RPC against a cluster.
BlockingRpcClient(Configuration, String, SocketAddress, MetricsConnection, Map<String, byte[]>) - Constructor for class org.apache.hadoop.hbase.ipc.BlockingRpcClient
Construct an IPC client for the cluster clusterId with the default SocketFactory This method is called with reflection by the RpcClientFactory to create an instance
BlockingServiceAndInterface(BlockingService, Class<?>) - Constructor for class org.apache.hadoop.hbase.ipc.RpcServer.BlockingServiceAndInterface
 
org.apache.hadoop.hbase.io.util.BlockIOUtils - Class in org.apache.hadoop.hbase.io.util
 
blockOffsets - Variable in class org.apache.hadoop.hbase.io.hfile.NoOpIndexBlockEncoder.NoOpEncodedSeeker
 
blockOnSync(SyncFuture) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
 
org.apache.hadoop.hbase.io.hfile.BlockPriority - Enum in org.apache.hadoop.hbase.io.hfile
 
blockSeek(Cell, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
Within a loaded block, seek looking for the last key that is smaller than (or equal to?) the key we are interested in.
blocksize - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
Block size to use writing files.
BLOCKSIZE - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
Size of storefile/hfile 'blocks'.
BLOCKSIZE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
org.apache.hadoop.hbase.io.hfile.BlockType - Enum in org.apache.hadoop.hbase.io.hfile
Various types of HFile blocks.
org.apache.hadoop.hbase.io.hfile.BlockType.BlockCategory - Enum in org.apache.hadoop.hbase.io.hfile
 
blockUntilAvailable() - Method in class org.apache.hadoop.hbase.zookeeper.ZKNodeTracker
Gets the data of the node, blocking until the node is available.
blockUntilAvailable(long, boolean) - Method in class org.apache.hadoop.hbase.zookeeper.ZKNodeTracker
Gets the data of the node, blocking until the node is available or the specified timeout has elapsed.
blockUpdates() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
org.apache.hadoop.hbase.io.hfile.BlockWithScanInfo - Class in org.apache.hadoop.hbase.io.hfile
BlockWithScanInfo is wrapper class for HFileBlock with other attributes.
BlockWithScanInfo(HFileBlock, Cell) - Constructor for class org.apache.hadoop.hbase.io.hfile.BlockWithScanInfo
 
blockWriter - Variable in class org.apache.hadoop.hbase.io.hfile.HFileWriterImpl
block writer
blockWritten(long, int, int) - Method in class org.apache.hadoop.hbase.io.hfile.CompoundBloomFilterWriter
 
blockWritten(long, int, int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexWriter
Called after an inline block has been written so that we can add an entry referring to that block to the parent-level index.
blockWritten(long, int, int) - Method in interface org.apache.hadoop.hbase.io.hfile.InlineBlockWriter
Called after a block has been written, and its offset, raw size, and compressed size have been determined.
bloom - Variable in class org.apache.hadoop.hbase.util.BloomFilterChunk
Bloom bits
BLOOM - Enum constant in enum org.apache.hadoop.hbase.io.hfile.BlockType.BlockCategory
 
BLOOM_CHUNK - Enum constant in enum org.apache.hadoop.hbase.io.hfile.BlockType
Bloom filter block, version 2
BLOOM_FILTER_DATA_KEY - Static variable in class org.apache.hadoop.hbase.io.hfile.HFile
Meta data block name for bloom filter bits.
BLOOM_FILTER_ELIGIBLE_REQUESTS_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOOM_FILTER_ELIGIBLE_REQUESTS_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOOM_FILTER_NEGATIVE_RESULTS_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOOM_FILTER_NEGATIVE_RESULTS_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOOM_FILTER_PARAM_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.HStoreFile
Bloom filter param in FileInfo
BLOOM_FILTER_REQUESTS_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOOM_FILTER_REQUESTS_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BLOOM_FILTER_TYPE_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.HStoreFile
Bloom filter Type in FileInfo
org.apache.hadoop.hbase.util.BloomContext - Class in org.apache.hadoop.hbase.util
The bloom context that is used by the StorefileWriter to add the bloom details per cell
BloomContext(BloomFilterWriter, CellComparator) - Constructor for class org.apache.hadoop.hbase.util.BloomContext
 
org.apache.hadoop.hbase.util.BloomFilter - Interface in org.apache.hadoop.hbase.util
Implements a Bloom filter, as defined by Bloom in 1970.
BLOOMFILTER - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
BLOOMFILTER - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
org.apache.hadoop.hbase.util.BloomFilterBase - Interface in org.apache.hadoop.hbase.util
Common methods Bloom filter methods required at read and write time.
org.apache.hadoop.hbase.util.BloomFilterChunk - Class in org.apache.hadoop.hbase.util
The basic building block for the CompoundBloomFilter
BloomFilterChunk(int, double, int, int) - Constructor for class org.apache.hadoop.hbase.util.BloomFilterChunk
Determines & initializes bloom filter meta data from user config.
BloomFilterChunk(int, BloomType) - Constructor for class org.apache.hadoop.hbase.util.BloomFilterChunk
 
BloomFilterChunk(DataInput) - Constructor for class org.apache.hadoop.hbase.util.BloomFilterChunk
Loads bloom filter meta data from file input.
org.apache.hadoop.hbase.util.BloomFilterFactory - Class in org.apache.hadoop.hbase.util
Handles Bloom filter initialization based on configuration and serialized metadata in the reader and writer of HStoreFile.
org.apache.hadoop.hbase.io.hfile.BloomFilterMetrics - Class in org.apache.hadoop.hbase.io.hfile
 
BloomFilterMetrics() - Constructor for class org.apache.hadoop.hbase.io.hfile.BloomFilterMetrics
 
bloomFilterType - Variable in class org.apache.hadoop.hbase.regionserver.StoreFileReader
 
org.apache.hadoop.hbase.util.BloomFilterUtil - Class in org.apache.hadoop.hbase.util
Utility methods related to BloomFilters
bloomFilterWriter - Variable in class org.apache.hadoop.hbase.util.BloomContext
 
org.apache.hadoop.hbase.util.BloomFilterWriter - Interface in org.apache.hadoop.hbase.util
Specifies methods needed to add elements to a Bloom filter and serialize the resulting Bloom filter as a sequence of bytes.
bloomType - Variable in class org.apache.hadoop.hbase.util.BloomFilterChunk
The type of bloom
org.apache.hadoop.hbase.regionserver.BloomType - Enum in org.apache.hadoop.hbase.regionserver
 
BLUE - Enum constant in enum org.apache.hadoop.hbase.hbtop.terminal.Color
 
BOGUS_SERVER_NAME - Static variable in interface org.apache.hadoop.hbase.master.LoadBalancer
 
BOOLEAN - Enum constant in enum org.apache.hadoop.hbase.util.PrettyPrinter.Unit
 
org.apache.hadoop.hbase.master.BooleanStateStore - Class in org.apache.hadoop.hbase.master
Store a boolean state.
BooleanStateStore(MasterRegion, String, ZKWatcher, String) - Constructor for class org.apache.hadoop.hbase.master.BooleanStateStore
 
BOOTSTRAP_NODES - Static variable in class org.apache.hadoop.hbase.client.RpcConnectionRegistry
 
org.apache.hadoop.hbase.regionserver.BootstrapNodeManager - Class in org.apache.hadoop.hbase.regionserver
Manage the bootstrap node list at region server side.
BootstrapNodeManager(ClusterConnection, MasterAddressTracker) - Constructor for class org.apache.hadoop.hbase.regionserver.BootstrapNodeManager
 
boundaries - Variable in class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter
 
BOUNDARIES_ERROR - Enum constant in enum org.apache.hadoop.hbase.util.HbckErrorReporter.ERROR_CODE
Deprecated.
 
BoundaryMultiWriter(CellComparator, List<byte[]>, byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter.BoundaryMultiWriter
 
BoundaryStripeFlushRequest(CellComparator, List<byte[]>) - Constructor for class org.apache.hadoop.hbase.regionserver.StripeStoreFlusher.BoundaryStripeFlushRequest
 
org.apache.hadoop.hbase.util.BoundedCompletionService<V> - Class in org.apache.hadoop.hbase.util
A completion service, close to the one available in the JDK 1.7 However, this ones keeps the list of the future, and allows to cancel them all.
BoundedCompletionService(Executor, int) - Constructor for class org.apache.hadoop.hbase.util.BoundedCompletionService
 
org.apache.hadoop.hbase.wal.BoundedEntryBuffers - Class in org.apache.hadoop.hbase.wal
Used for BoundedRecoveredEditsOutputSink.
BoundedEntryBuffers(WALSplitter.PipelineController, long) - Constructor for class org.apache.hadoop.hbase.wal.BoundedEntryBuffers
 
org.apache.hadoop.hbase.wal.BoundedGroupingStrategy - Class in org.apache.hadoop.hbase.wal
A WAL grouping strategy that limits the number of wal groups to "hbase.wal.regiongrouping.numgroups".
BoundedGroupingStrategy() - Constructor for class org.apache.hadoop.hbase.wal.BoundedGroupingStrategy
 
org.apache.hadoop.hbase.util.BoundedPriorityBlockingQueue<E> - Class in org.apache.hadoop.hbase.util
A generic bounded blocking Priority-Queue.
BoundedPriorityBlockingQueue(int, Comparator<? super E>) - Constructor for class org.apache.hadoop.hbase.util.BoundedPriorityBlockingQueue
Creates a PriorityQueue with the specified capacity that orders its elements according to the specified comparator.
org.apache.hadoop.hbase.wal.BoundedRecoveredHFilesOutputSink - Class in org.apache.hadoop.hbase.wal
A WALSplitter sink that outputs HFiles.
BoundedRecoveredHFilesOutputSink(WALSplitter, WALSplitter.PipelineController, EntryBuffers, int) - Constructor for class org.apache.hadoop.hbase.wal.BoundedRecoveredHFilesOutputSink
 
org.apache.hadoop.hbase.tool.coprocessor.Branch1CoprocessorMethods - Class in org.apache.hadoop.hbase.tool.coprocessor
 
Branch1CoprocessorMethods() - Constructor for class org.apache.hadoop.hbase.tool.coprocessor.Branch1CoprocessorMethods
 
BROKEN_STOREFILE_CLEANER_DELAY - Static variable in class org.apache.hadoop.hbase.regionserver.BrokenStoreFileCleaner
 
BROKEN_STOREFILE_CLEANER_DELAY_JITTER - Static variable in class org.apache.hadoop.hbase.regionserver.BrokenStoreFileCleaner
 
BROKEN_STOREFILE_CLEANER_ENABLED - Static variable in class org.apache.hadoop.hbase.regionserver.BrokenStoreFileCleaner
 
BROKEN_STOREFILE_CLEANER_PERIOD - Static variable in class org.apache.hadoop.hbase.regionserver.BrokenStoreFileCleaner
 
BROKEN_STOREFILE_CLEANER_TTL - Static variable in class org.apache.hadoop.hbase.regionserver.BrokenStoreFileCleaner
 
org.apache.hadoop.hbase.regionserver.BrokenStoreFileCleaner - Class in org.apache.hadoop.hbase.regionserver
This Chore, every time it runs, will clear the unsused HFiles in the data folder.
BrokenStoreFileCleaner(int, int, Stoppable, Configuration, HRegionServer) - Constructor for class org.apache.hadoop.hbase.regionserver.BrokenStoreFileCleaner
 
BROTLI - Enum constant in enum org.apache.hadoop.hbase.io.compress.Compression.Algorithm
 
BROTLI_CODEC_CLASS_DEFAULT - Static variable in class org.apache.hadoop.hbase.io.compress.Compression
 
BROTLI_CODEC_CLASS_KEY - Static variable in class org.apache.hadoop.hbase.io.compress.Compression
 
BUCKET_CACHE_BUCKETS_KEY - Static variable in class org.apache.hadoop.hbase.io.hfile.BlockCacheFactory
A comma-delimited array of values for use as bucket sizes.
BUCKET_CACHE_IOENGINE_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
Current ioengine options in include: heap, offheap and file:PATH (where PATH is the path to the file that will host the file-based cache.
BUCKET_CACHE_PERSISTENT_PATH_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
If the chosen ioengine can persist its state across restarts, the path to the file to persist to.
BUCKET_CACHE_SIZE_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
When using bucket cache, it is the capacity in megabytes of the cache.
BUCKET_CACHE_WRITER_QUEUE_KEY - Static variable in class org.apache.hadoop.hbase.io.hfile.BlockCacheFactory
 
BUCKET_CACHE_WRITER_THREADS_KEY - Static variable in class org.apache.hadoop.hbase.io.hfile.BlockCacheFactory
 
BUCKETCACHE_PERSIST_INTERVAL_KEY - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
Configuration key to set interval for persisting bucket cache to disk.
buf - Variable in class org.apache.hadoop.hbase.ByteBufferKeyValue
 
buf - Variable in class org.apache.hadoop.hbase.codec.KeyValueCodec.ByteBuffKeyValueDecoder
 
BUFFER_SIZE_KEY - Static variable in class org.apache.hadoop.hbase.io.ByteBuffAllocator
 
buffered() - Method in interface org.apache.hadoop.hbase.io.asyncfs.AsyncFSOutput
Return the current size of buffered data.
buffered() - Method in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutput
 
buffered() - Method in class org.apache.hadoop.hbase.io.asyncfs.WrapperAsyncFSOutput
 
org.apache.hadoop.hbase.client.BufferedMutator - Interface in org.apache.hadoop.hbase.client
Used to communicate with a single HBase table similar to Table but meant for batched, asynchronous puts.
org.apache.hadoop.hbase.client.BufferedMutator.ExceptionListener - Interface in org.apache.hadoop.hbase.client
Listens for asynchronous exceptions on a BufferedMutator.
org.apache.hadoop.hbase.client.example.BufferedMutatorExample - Class in org.apache.hadoop.hbase.client.example
An example of using the BufferedMutator interface.
BufferedMutatorExample() - Constructor for class org.apache.hadoop.hbase.client.example.BufferedMutatorExample
 
org.apache.hadoop.hbase.client.BufferedMutatorImpl - Class in org.apache.hadoop.hbase.client
Used to communicate with a single HBase table similar to Table but meant for batched, potentially asynchronous puts.
org.apache.hadoop.hbase.client.BufferedMutatorParams - Class in org.apache.hadoop.hbase.client
Parameters for instantiating a BufferedMutator.
BufferedMutatorParams(TableName) - Constructor for class org.apache.hadoop.hbase.client.BufferedMutatorParams
 
bufSize - Variable in class org.apache.hadoop.hbase.io.ByteBuffAllocator
 
build() - Method in class org.apache.hadoop.hbase.backup.BackupRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.backup.RestoreRequest.Builder
 
build() - Method in class org.apache.hadoop.hbase.CacheEvictionStatsBuilder
 
build() - Method in interface org.apache.hadoop.hbase.CellBuilder
 
build() - Method in interface org.apache.hadoop.hbase.client.AsyncAdminBuilder
Create a AsyncAdmin instance.
build() - Method in interface org.apache.hadoop.hbase.client.AsyncBufferedMutatorBuilder
Create the AsyncBufferedMutator instance.
build() - Method in class org.apache.hadoop.hbase.client.AsyncProcessTask.Builder
 
build() - Method in interface org.apache.hadoop.hbase.client.AsyncTableBuilder
Create the AsyncTable instance.
build() - Method in class org.apache.hadoop.hbase.client.BalancerDecision.Builder
 
build() - Method in class org.apache.hadoop.hbase.client.BalanceRequest.Builder
Build the BalanceRequest
build() - Method in class org.apache.hadoop.hbase.client.BalanceResponse.Builder
Build the BalanceResponse
build() - Method in class org.apache.hadoop.hbase.client.BalancerRejection.Builder
 
build() - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
build() - Method in class org.apache.hadoop.hbase.client.CoprocessorDescriptorBuilder
 
build() - Method in class org.apache.hadoop.hbase.client.NormalizeTableFilterParams.Builder
 
build() - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord.OnlineLogRecordBuilder
 
build() - Method in class org.apache.hadoop.hbase.client.RegionInfoBuilder
 
build() - Method in class org.apache.hadoop.hbase.client.RegionStatesCount.RegionStatesCountBuilder
 
build() - Method in interface org.apache.hadoop.hbase.client.TableBuilder
Create the Table instance.
build() - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
 
build() - Method in class org.apache.hadoop.hbase.client.trace.ConnectionSpanBuilder
 
build() - Method in class org.apache.hadoop.hbase.client.trace.IpcClientSpanBuilder
 
build() - Method in class org.apache.hadoop.hbase.client.trace.TableOperationSpanBuilder
 
build() - Method in class org.apache.hadoop.hbase.client.trace.TableSpanBuilder
 
build() - Method in class org.apache.hadoop.hbase.ClusterMetricsBuilder
 
build() - Method in interface org.apache.hadoop.hbase.ExtendedCellBuilder
 
build() - Method in class org.apache.hadoop.hbase.ExtendedCellBuilderImpl
 
build() - Method in class org.apache.hadoop.hbase.hbtop.Record.Builder
 
build() - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
 
build() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockBuilder
 
build() - Method in class org.apache.hadoop.hbase.io.hfile.HFileContextBuilder
 
build() - Method in class org.apache.hadoop.hbase.io.hfile.ReaderContextBuilder
 
build() - Method in class org.apache.hadoop.hbase.NamespaceDescriptor.Builder
 
build() - Method in interface org.apache.hadoop.hbase.RawCellBuilder
 
build() - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder
 
build() - Method in class org.apache.hadoop.hbase.regionserver.CustomizedScanInfoBuilder
 
build() - Method in class org.apache.hadoop.hbase.regionserver.ScannerContext.Builder
 
build() - Method in class org.apache.hadoop.hbase.regionserver.StoreContext.Builder
 
build() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileWriter.Builder
Create a store file writer.
build() - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSink.ReplicationLoadSinkBuilder
 
build() - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSource.ReplicationLoadSourceBuilder
 
build() - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeerConfigBuilder
Builds the configuration object from the current state of this.
build() - Method in class org.apache.hadoop.hbase.server.trace.IpcServerSpanBuilder
 
build() - Method in class org.apache.hadoop.hbase.ServerMetricsBuilder
 
build() - Method in class org.apache.hadoop.hbase.ServerTaskBuilder
 
build() - Method in interface org.apache.hadoop.hbase.TagBuilder
Build the tag.
build() - Method in class org.apache.hadoop.hbase.testing.TestingHBaseClusterOption.Builder
 
build() - Method in class org.apache.hadoop.hbase.UserMetricsBuilder
 
build() - Method in class org.apache.hadoop.hbase.util.RegionMover.RegionMoverBuilder
This method builds the appropriate RegionMover object which can then be used to load/unload using load and unload methods
build(Configuration, TableName, String, String, String) - Static method in class org.apache.hadoop.hbase.io.HFileLink
Create an HFileLink instance from table/region/family/hfile location
build(Append) - Method in class org.apache.hadoop.hbase.client.CheckAndMutate.Builder
Build the CheckAndMutate object with an Append to commit if the check succeeds.
build(Delete) - Method in class org.apache.hadoop.hbase.client.CheckAndMutate.Builder
Build the CheckAndMutate object
build(Increment) - Method in class org.apache.hadoop.hbase.client.CheckAndMutate.Builder
Build the CheckAndMutate object with an Increment to commit if the check succeeds.
build(Put) - Method in class org.apache.hadoop.hbase.client.CheckAndMutate.Builder
Build the CheckAndMutate object
build(RowMutations) - Method in class org.apache.hadoop.hbase.client.CheckAndMutate.Builder
Build the CheckAndMutate object with a RowMutations to commit if the check succeeds.
buildActionResult(Throwable) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ResponseConverter
Wrap a throwable to an action result.
buildActionResult(ClientProtos.Result) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ResponseConverter
Wrap a throwable to an action result.
buildAddColumnRequest(TableName, ColumnFamilyDescriptor, long, long) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Create a protocol buffer AddColumnRequest
buildAddReplicationPeerRequest(String, ReplicationPeerConfig, boolean) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
 
buildAssignRegionRequest(byte[]) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Create a protocol buffer AssignRegionRequest
buildBulkLoadHFileRequest(List<Pair<byte[], String>>, byte[], boolean, Token<?>, String) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Create a protocol buffer bulk load request
buildBulkLoadHFileRequest(List<Pair<byte[], String>>, byte[], boolean, Token<?>, String, boolean, List<String>, boolean) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Create a protocol buffer bulk load request
buildCatalogScanRequest() - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Creates a request for running a catalog scan
buildClearCompactionQueuesRequest(Set<String>) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
 
buildClearDeadServersRequest(Collection<ServerName>) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
 
buildClearRegionBlockCacheRequest(List<RegionInfo>) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Creates a protocol buffer ClearRegionBlockCacheRequest
buildClearRegionBlockCacheResponse(HBaseProtos.CacheEvictionStats) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ResponseConverter
Creates a protocol buffer ClearRegionBlockCacheResponse
buildClearSlowLogResponseRequest() - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Create a protocol buffer AdminProtos.ClearSlowLogResponseRequest
buildCloseRegionRequest(ServerName, byte[]) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
Create a CloseRegionRequest for a given region name
buildCloseRegionRequest(ServerName, byte[], ServerName) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
 
buildCloseRegionRequest(ServerName, byte[], ServerName, long) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
 
buildCloseRegionRequest(ServerName, byte[], ServerName, long, boolean) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
 
buildCompactRegionRequest(byte[], boolean, byte[]) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Create a CompactRegionRequest for a given region name
buildCreateNamespaceRequest(NamespaceDescriptor) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Creates a protocol buffer CreateNamespaceRequest
buildCreateTableRequest(TableDescriptor, byte[][], long, long) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Creates a protocol buffer CreateTableRequest
buildDecommissionRegionServersRequest(List<ServerName>, boolean) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
 
buildDefaultUserQuotaState(Configuration, long) - Static method in class org.apache.hadoop.hbase.quotas.QuotaUtil
 
buildDeleteColumnRequest(TableName, byte[], long, long) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Create a protocol buffer DeleteColumnRequest
buildDeleteNamespaceRequest(String) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Creates a protocol buffer DeleteNamespaceRequest
buildDeleteTableRequest(TableName, long, long) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Creates a protocol buffer DeleteTableRequest
buildDependencyClasspath(Configuration) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Returns a classpath string built from the content of the "tmpjars" value in conf.
buildDisableReplicationPeerRequest(String) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
 
buildDisableTableRequest(TableName, long, long) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Creates a protocol buffer DisableTableRequest
buildEnableCatalogJanitorRequest(boolean) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Creates a request for enabling/disabling the catalog janitor
buildEnableCatalogJanitorResponse(boolean) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ResponseConverter
Creates a response for the catalog scan request
buildEnableReplicationPeerRequest(String) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
 
buildEnableTableRequest(TableName, long, long) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Creates a protocol buffer EnableTableRequest
builder() - Static method in class org.apache.hadoop.hbase.CacheEvictionStats
 
builder() - Static method in class org.apache.hadoop.hbase.hbtop.Record
 
builder() - Static method in class org.apache.hadoop.hbase.testing.TestingHBaseClusterOption
Returns a new builder.
Builder() - Constructor for class org.apache.hadoop.hbase.backup.BackupRequest.Builder
 
Builder() - Constructor for class org.apache.hadoop.hbase.backup.RestoreRequest.Builder
 
Builder() - Constructor for class org.apache.hadoop.hbase.client.BalancerDecision.Builder
 
Builder() - Constructor for class org.apache.hadoop.hbase.client.BalancerRejection.Builder
 
Builder() - Constructor for class org.apache.hadoop.hbase.client.NormalizeTableFilterParams.Builder
 
Builder() - Constructor for class org.apache.hadoop.hbase.http.HttpServer.Builder
 
Builder() - Constructor for class org.apache.hadoop.hbase.regionserver.StoreContext.Builder
 
Builder(Configuration, FileSystem) - Constructor for class org.apache.hadoop.hbase.regionserver.StoreFileWriter.Builder
Creates Builder with cache configuration disabled
Builder(Configuration, CacheConfig, FileSystem) - Constructor for class org.apache.hadoop.hbase.regionserver.StoreFileWriter.Builder
 
buildException(Throwable) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ResponseConverter
Returns NameValuePair of the exception name to stringified version os exception.
buildFileArchiveRequest(TableName, Collection<Map.Entry<String, Long>>) - Method in class org.apache.hadoop.hbase.quotas.RegionServerSpaceQuotaManager
Builds the protobuf message to inform the Master of files being archived.
buildFilter(String) - Static method in class org.apache.hadoop.hbase.rest.ResultGenerator
 
buildFilterFromModel(ScannerModel) - Static method in class org.apache.hadoop.hbase.rest.ScannerResultGenerator
 
buildFlushRegionRequest(byte[]) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Create a protocol buffer FlushRegionRequest for a given region name
buildFlushRegionRequest(byte[], byte[], boolean) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Create a protocol buffer FlushRegionRequest for a given region name
buildFlushTableRequest(TableName, List<byte[]>, long, long) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
 
buildFromHFileLinkPattern(Configuration, Path) - Static method in class org.apache.hadoop.hbase.io.HFileLink
 
buildFromHFileLinkPattern(Path, Path, Path) - Static method in class org.apache.hadoop.hbase.io.HFileLink
 
buildFromProto(MasterProtos.SetQuotaRequest) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettings
Converts the protocol buffer request into a QuotaSetting POJO.
buildGetClusterStatusRequest(EnumSet<ClusterMetrics.Option>) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Creates a protocol buffer GetClusterStatusRequest
buildGetLastFlushedSequenceIdRequest(byte[]) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Creates a request for querying the master the last flushed sequence Id for a region
buildGetLastFlushedSequenceIdResponse(ClusterStatusProtos.RegionStoreSequenceIds) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ResponseConverter
Creates a response for the last flushed sequence Id request
buildGetNamespaceDescriptorRequest(String) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Creates a protocol buffer GetNamespaceDescriptorRequest
buildGetOnlineRegionRequest() - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Create a protocol buffer GetOnlineRegionRequest
buildGetOnlineRegionResponse(List<RegionInfo>) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ResponseConverter
A utility to build a GetOnlineRegionResponse.
buildGetQuotaStatesRequest() - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Returns a QuotaProtos.GetQuotaStatesRequest object.
buildGetRegionInfoRequest(byte[]) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Create a protocol buffer GetRegionInfoRequest for a given region name
buildGetRegionInfoRequest(byte[], boolean) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Create a protocol buffer GetRegionInfoRequest for a given region name
buildGetRegionInfoRequest(byte[], boolean, boolean) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Create a protocol buffer GetRegionInfoRequest,
buildGetRegionLoadRequest(TableName) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Create a protocol buffer GetRegionLoadRequest for all regions/regions of a table.
buildGetReplicationPeerConfigRequest(String) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
 
buildGetRequest(byte[], Get) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Create a protocol buffer GetRequest for a client Get
buildGetSchemaAlterStatusRequest(TableName) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Creates a protocol buffer GetSchemaAlterStatusRequest
buildGetServerInfoRequest() - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Create a new GetServerInfoRequest
buildGetServerInfoResponse(ServerName, int) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ResponseConverter
A utility to build a GetServerInfoResponse.
buildGetSpaceQuotaRegionSizesRequest() - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Returns a QuotaProtos.GetSpaceQuotaRegionSizesRequest object.
buildGetSpaceQuotaSnapshotsRequest() - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Returns a QuotaProtos.GetSpaceQuotaSnapshotsRequest object.
buildGetStoreFileRequest(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
Create a protocol buffer GetStoreFileRequest for a given region name
buildGetTableDescriptorsRequest(List<TableName>) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Creates a protocol buffer GetTableDescriptorsRequest
buildGetTableDescriptorsRequest(Pattern, boolean) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Creates a protocol buffer GetTableDescriptorsRequest
buildGetTableDescriptorsRequest(TableName) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Creates a protocol buffer GetTableDescriptorsRequest for a single table
buildGetTableNamesRequest(Pattern, boolean) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Creates a protocol buffer GetTableNamesRequest
buildGetTableStateRequest(TableName) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Creates a protocol buffer GetTableStateRequest
buildGzipHandler(Handler) - Static method in class org.apache.hadoop.hbase.http.HttpServer
Construct and configure an instance of GzipHandler.
buildHasPermissionResponse(boolean) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ResponseConverter
Builds a protocol buffer HasPermissionResponse
buildIncrementRequest(byte[], byte[], byte[], byte[], long, Durability, long, long) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Create a protocol buffer MutateRequest for a client increment
buildIsBalancerEnabledRequest() - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Creates a protocol buffer IsBalancerEnabledRequest
buildIsCatalogJanitorEnabledRequest() - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Creates a request for querying the master whether the catalog janitor is enabled
buildIsCleanerChoreEnabledRequest() - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Creates a request for querying the master whether the cleaner chore is enabled
buildIsMasterRunningRequest() - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Creates a protocol buffer IsMasterRunningRequest
buildIsNormalizerEnabledRequest() - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Creates a protocol buffer IsNormalizerEnabledRequest
buildIsSnapshotCleanupEnabledRequest() - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Creates IsSnapshotCleanupEnabledRequest to determine if auto snapshot cleanup based on TTL expiration is turned on
buildIsSplitOrMergeEnabledRequest(MasterSwitchType) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Creates a protocol buffer IsSplitOrMergeEnabledRequest
buildJMXServiceURL(int, int) - Static method in class org.apache.hadoop.hbase.JMXListener
 
buildListReplicationPeersRequest(Pattern) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
 
buildLockRequest(LockServiceProtos.LockType, String, TableName, List<RegionInfo>, String, long, long) - Static method in class org.apache.hadoop.hbase.client.locking.LockServiceClient
 
buildMergeTableRegionsRequest(byte[][], boolean, long, long) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
 
buildModifyColumnRequest(TableName, ColumnFamilyDescriptor, long, long) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Create a protocol buffer ModifyColumnRequest
buildModifyColumnStoreFileTrackerRequest(TableName, byte[], String, long, long) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
 
buildModifyNamespaceRequest(NamespaceDescriptor) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Creates a protocol buffer ModifyNamespaceRequest
buildModifyTableRequest(TableName, TableDescriptor, long, long, boolean) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Creates a protocol buffer ModifyTableRequest
buildModifyTableStoreFileTrackerRequest(TableName, String, long, long) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
 
buildMoveRegionRequest(byte[], ServerName) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Create a protocol buffer MoveRegionRequest
buildMultiRequest(byte[], byte[], byte[], byte[], CompareOperator, byte[], Filter, TimeRange, RowMutations, long, long) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Create a protocol buffer MultiRequest for conditioned row mutations
buildMultiRequest(byte[], RowMutations, long, long) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Create a protocol buffer MultiRequest for row mutations
buildMutateRequest(byte[], byte[], byte[], byte[], CompareOperator, byte[], Filter, TimeRange, Mutation, long, long) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Create a protocol buffer MutateRequest for a conditioned put/delete/increment/append
buildMutateRequest(byte[], Append, long, long) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Create a protocol buffer MutateRequest for an append
buildMutateRequest(byte[], Delete) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Create a protocol buffer MutateRequest for a delete
buildMutateRequest(byte[], Increment, long, long) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Create a protocol buffer MutateRequest for a client increment
buildMutateRequest(byte[], Put) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Create a protocol buffer MutateRequest for a put
buildNoDataRegionActions(byte[], Iterable<Action>, List<CellScannable>, ClientProtos.MultiRequest.Builder, ClientProtos.RegionAction.Builder, ClientProtos.Action.Builder, ClientProtos.MutationProto.Builder, long, Map<Integer, Integer>) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Create a protocol buffer multirequest with NO data for a list of actions (data is carried otherwise than via protobuf).
buildNormalizeRequest(NormalizeTableFilterParams) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Creates a protocol buffer NormalizeRequest
buildObjectName(String) - Static method in class org.apache.hadoop.hbase.util.JSONMetricUtil
 
buildObjectName(String, Hashtable<String, String>) - Static method in class org.apache.hadoop.hbase.util.JSONMetricUtil
 
buildOfflineRegionRequest(byte[]) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Creates a protocol buffer OfflineRegionRequest
buildOpenRegionRequest(ServerName, RegionInfo, List<ServerName>) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Create a protocol buffer OpenRegionRequest for a given region
buildProcedureDescription(String, String, Map<String, String>) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
 
buildRecommissionRegionServerRequest(ServerName, List<byte[]>) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
 
buildRegionActions(byte[], List<Action>, ClientProtos.MultiRequest.Builder, ClientProtos.RegionAction.Builder, ClientProtos.Action.Builder, ClientProtos.MutationProto.Builder, long, Map<Integer, Integer>) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Create a protocol buffer multi request for a list of actions.
buildRegionOpenInfo(RegionInfo, List<ServerName>, long) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Create a RegionOpenInfo based on given region info and version of offline node
buildRegionSpecifier(HBaseProtos.RegionSpecifier.RegionSpecifierType, byte[]) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Convert a byte array to a protocol buffer RegionSpecifier
buildRemoveReplicationPeerRequest(String) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
 
buildRollWALWriterRequest() - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Create a new RollWALWriterRequest
buildRunCatalogScanResponse(int) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ResponseConverter
Creates a response for the catalog scan request
buildRunCleanerChoreRequest() - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Creates a request for running cleaner chore
buildRunCleanerChoreResponse(boolean) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ResponseConverter
Creates a response for the cleaner chore request
buildScanRequest(byte[], Scan, int, boolean) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Create a protocol buffer ScanRequest for a client Scan
buildScanRequest(long, int, boolean, boolean) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Create a protocol buffer ScanRequest for a scanner id
buildScanRequest(long, int, boolean, long, boolean, boolean, int) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Create a protocol buffer ScanRequest for a scanner id
buildSetBalancerRunningRequest(boolean, boolean) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Creates a protocol buffer SetBalancerRunningRequest
buildSetCleanerChoreRunningRequest(boolean) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Creates a request for enabling/disabling the cleaner chore
buildSetNormalizerRunningRequest(boolean) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Creates a protocol buffer SetNormalizerRunningRequest
buildSetQuotaRequestProto(QuotaSettings) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettings
Convert a QuotaSettings to a protocol buffer SetQuotaRequest.
buildSetRegionStateInMetaRequest(Map<String, RegionState.State>) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Creates a protocol buffer SetRegionStateInMetaRequest
buildSetSnapshotCleanupRequest(boolean, boolean) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Creates SetSnapshotCleanupRequest for turning on/off auto snapshot cleanup
buildSetSplitOrMergeEnabledRequest(boolean, boolean, MasterSwitchType...) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Creates a protocol buffer SetSplitOrMergeEnabledRequest
buildSetTableStateInMetaRequest(TableState) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Creates a protocol buffer SetTableStateInMetaRequest
buildSlowLogResponseRequest(Map<String, Object>, int, String) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Build RPC request payload for getLogEntries
buildSpanName(String, String) - Static method in class org.apache.hadoop.hbase.client.trace.IpcClientSpanBuilder
Construct an RPC span name.
buildSplitTableRegionRequest(RegionInfo, byte[], long, long) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
 
buildStopServerRequest(String) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Create a new StopServerRequest
buildTruncateRegionRequest(RegionInfo, long, long) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
 
buildTruncateTableRequest(TableName, boolean, long, long) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Creates a protocol buffer TruncateTableRequest
buildUnassignRegionRequest(byte[]) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Creates a protocol buffer UnassignRegionRequest
buildUpdateFavoredNodesRequest(List<Pair<RegionInfo, List<ServerName>>>) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Create a protocol buffer UpdateFavoredNodesRequest to update a list of favorednode mappings
buildUpdateReplicationPeerConfigRequest(String, ReplicationPeerConfig) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
 
buildWarmupRegionRequest(RegionInfo) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Create a WarmupRegionRequest for a given region name
buildZKQuorumServerString(String[], String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKConfig
Build the ZK quorum server string with "server:clientport" list, separated by ','
buldKeyValueTable(String[], String[]) - Static method in class org.apache.hadoop.hbase.util.JSONMetricUtil
Method for building map used for constructing ObjectName.
BULK_LOAD - Static variable in class org.apache.hadoop.hbase.wal.WALEdit
 
BULK_OUTPUT_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.Import
 
BULK_OUTPUT_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv
 
BULK_OUTPUT_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.WALPlayer
 
BULKLOAD_DIR_NAME - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
Old configuration parameters (obsolete)
BULKLOAD_MAX_RETRIES_NUMBER - Static variable in class org.apache.hadoop.hbase.HConstants
Maximum time to retry for a failed bulk load request
BULKLOAD_QOS - Static variable in class org.apache.hadoop.hbase.HConstants
 
BULKLOAD_QUEUE_DESC - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
BULKLOAD_QUEUE_NAME - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
BULKLOAD_STAGING_DIR_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
Staging dir used by bulk load
BULKLOAD_TASK_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.HStoreFile
Meta key set when store file is a result of a bulk load
BULKLOAD_TIME_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.HStoreFile
 
org.apache.hadoop.hbase.replication.BulkLoadCellFilter - Class in org.apache.hadoop.hbase.replication
 
BulkLoadCellFilter() - Constructor for class org.apache.hadoop.hbase.replication.BulkLoadCellFilter
 
bulkLoadHFile(byte[], String, Path) - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
bulkLoadHFile(StoreFileInfo) - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
bulkLoadHFile(RpcController, ClientProtos.BulkLoadHFileRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
Atomically bulk load several HFiles into an open region
bulkLoadHFiles(Collection<Pair<byte[], String>>, boolean, HRegion.BulkLoadListener) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Attempts to atomically load a group of hfiles.
bulkLoadHFiles(Collection<Pair<byte[], String>>, boolean, HRegion.BulkLoadListener, boolean, List<String>, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Attempts to atomically load a group of hfiles.
org.apache.hadoop.hbase.coprocessor.BulkLoadObserver - Interface in org.apache.hadoop.hbase.coprocessor
Coprocessors implement this interface to observe and mediate bulk load operations.
org.apache.hadoop.hbase.regionserver.BusyRegionSplitPolicy - Class in org.apache.hadoop.hbase.regionserver
This class represents a split policy which makes the split decision based on how busy a region is.
BusyRegionSplitPolicy() - Constructor for class org.apache.hadoop.hbase.regionserver.BusyRegionSplitPolicy
 
bypass() - Method in interface org.apache.hadoop.hbase.coprocessor.ObserverContext
Call to indicate that the current coprocessor's return value (or parameter -- depends on the call-type) should be used in place of the value that would be obtained via normal processing; i.e.
bypass() - Method in class org.apache.hadoop.hbase.coprocessor.ObserverContextImpl
 
bypassGlobals(String, boolean) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
Set the "bypass global settings" for the specified user
bypassProcedure(List<Long>, long, boolean, boolean) - Method in class org.apache.hadoop.hbase.client.HBaseHbck
 
bypassProcedure(List<Long>, long, boolean, boolean) - Method in interface org.apache.hadoop.hbase.client.Hbck
Bypass specified procedure and move it to completion.
bypassProcedure(RpcController, MasterProtos.BypassProcedureRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
Bypass specified procedure to completion.
BYTE - Enum constant in enum org.apache.hadoop.hbase.Size.Unit
 
BYTE - Enum constant in enum org.apache.hadoop.hbase.util.PrettyPrinter.Unit
 
BYTE_ARRAY_BASE_OFFSET - Static variable in class org.apache.hadoop.hbase.util.UnsafeAccess
The offset to the first element in a byte array.
BYTE_BUFF_ALLOCATOR_HEAP_ALLOCATION_BYTES - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
Metrics for ByteBuffAllocator
BYTE_BUFF_ALLOCATOR_HEAP_ALLOCATION_BYTES_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BYTE_BUFF_ALLOCATOR_HEAP_ALLOCATION_RATIO - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BYTE_BUFF_ALLOCATOR_HEAP_ALLOCATION_RATIO_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BYTE_BUFF_ALLOCATOR_POOL_ALLOCATION_BYTES - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BYTE_BUFF_ALLOCATOR_POOL_ALLOCATION_BYTES_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BYTE_BUFF_ALLOCATOR_TOTAL_BUFFER_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BYTE_BUFF_ALLOCATOR_TOTAL_BUFFER_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BYTE_BUFF_ALLOCATOR_USED_BUFFER_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BYTE_BUFF_ALLOCATOR_USED_BUFFER_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
BYTE_BUFFER - Static variable in class org.apache.hadoop.hbase.util.ClassSize
Overhead for ByteBuffer
org.apache.hadoop.hbase.filter.ByteArrayComparable - Class in org.apache.hadoop.hbase.filter
Base class for byte array comparators
ByteArrayComparable(byte[]) - Constructor for class org.apache.hadoop.hbase.filter.ByteArrayComparable
Constructor.
ByteArrayComparator() - Constructor for class org.apache.hadoop.hbase.util.Bytes.ByteArrayComparator
 
org.apache.hadoop.hbase.util.ByteArrayHashKey - Class in org.apache.hadoop.hbase.util
 
ByteArrayHashKey(byte[], int, int) - Constructor for class org.apache.hadoop.hbase.util.ByteArrayHashKey
 
org.apache.hadoop.hbase.io.ByteArrayOutputStream - Class in org.apache.hadoop.hbase.io
Our own implementation of ByteArrayOutputStream where all methods are NOT synchronized and supports writing ByteBuffer directly to it.
ByteArrayOutputStream() - Constructor for class org.apache.hadoop.hbase.io.ByteArrayOutputStream
 
ByteArrayOutputStream(int) - Constructor for class org.apache.hadoop.hbase.io.ByteArrayOutputStream
 
org.apache.hadoop.hbase.http.gson.ByteArraySerializer - Class in org.apache.hadoop.hbase.http.gson
Serialize a byte[] using Bytes.toString().
ByteArraySerializer() - Constructor for class org.apache.hadoop.hbase.http.gson.ByteArraySerializer
 
org.apache.hadoop.hbase.nio.ByteBuff - Class in org.apache.hadoop.hbase.nio
An abstract class that abstracts out as to how the byte buffers are used, either single or multiple.
ByteBuff() - Constructor for class org.apache.hadoop.hbase.nio.ByteBuff
 
BYTEBUFF_ALLOCATOR_CLASS - Static variable in class org.apache.hadoop.hbase.io.ByteBuffAllocator
Set an alternate bytebuffallocator by setting this config, e.g.
org.apache.hadoop.hbase.io.ByteBuffAllocator - Class in org.apache.hadoop.hbase.io
ByteBuffAllocator is used for allocating/freeing the ByteBuffers from/to NIO ByteBuffer pool, and it provide high-level interfaces for upstream.
ByteBuffAllocator(boolean, int, int, int) - Constructor for class org.apache.hadoop.hbase.io.ByteBuffAllocator
 
org.apache.hadoop.hbase.io.ByteBuffAllocator.Recycler - Interface in org.apache.hadoop.hbase.io
 
org.apache.hadoop.hbase.util.ByteBufferAllocator - Interface in org.apache.hadoop.hbase.util
Defines the way the ByteBuffers are created
org.apache.hadoop.hbase.util.ByteBufferArray - Class in org.apache.hadoop.hbase.util
This class manages an array of ByteBuffers with a default size 4MB.
ByteBufferArray(long, ByteBufferAllocator) - Constructor for class org.apache.hadoop.hbase.util.ByteBufferArray
We allocate a number of byte buffers as the capacity.
org.apache.hadoop.hbase.regionserver.ByteBufferChunkKeyValue - Class in org.apache.hadoop.hbase.regionserver
ByteBuffer based cell which has the chunkid at the 0th offset
ByteBufferChunkKeyValue(ByteBuffer, int, int) - Constructor for class org.apache.hadoop.hbase.regionserver.ByteBufferChunkKeyValue
 
ByteBufferChunkKeyValue(ByteBuffer, int, int, long) - Constructor for class org.apache.hadoop.hbase.regionserver.ByteBufferChunkKeyValue
 
org.apache.hadoop.hbase.ByteBufferExtendedCell - Class in org.apache.hadoop.hbase
This class is a server side extension to the Cell interface.
ByteBufferExtendedCell() - Constructor for class org.apache.hadoop.hbase.ByteBufferExtendedCell
 
org.apache.hadoop.hbase.io.ByteBufferInputStream - Class in org.apache.hadoop.hbase.io
Not thread safe!
ByteBufferInputStream(ByteBuffer) - Constructor for class org.apache.hadoop.hbase.io.ByteBufferInputStream
 
org.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValue - Class in org.apache.hadoop.hbase
This is a key only Cell implementation which is identical to KeyValue.KeyOnlyKeyValue with respect to key serialization but have its data in the form of Byte buffer (onheap and offheap).
ByteBufferKeyOnlyKeyValue() - Constructor for class org.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValue
Used in cases where we want to avoid lot of garbage by allocating new objects with different keys.
ByteBufferKeyOnlyKeyValue(ByteBuffer, int, int) - Constructor for class org.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValue
 
org.apache.hadoop.hbase.ByteBufferKeyValue - Class in org.apache.hadoop.hbase
This Cell is an implementation of ByteBufferExtendedCell where the data resides in off heap/ on heap ByteBuffer
ByteBufferKeyValue(ByteBuffer, int, int) - Constructor for class org.apache.hadoop.hbase.ByteBufferKeyValue
 
ByteBufferKeyValue(ByteBuffer, int, int, long) - Constructor for class org.apache.hadoop.hbase.ByteBufferKeyValue
 
org.apache.hadoop.hbase.io.ByteBufferListOutputStream - Class in org.apache.hadoop.hbase.io
An OutputStream which writes data into ByteBuffers.
ByteBufferListOutputStream(ByteBuffAllocator) - Constructor for class org.apache.hadoop.hbase.io.ByteBufferListOutputStream
 
org.apache.hadoop.hbase.io.ByteBufferOutputStream - Class in org.apache.hadoop.hbase.io
Not thread safe!
ByteBufferOutputStream(int) - Constructor for class org.apache.hadoop.hbase.io.ByteBufferOutputStream
 
ByteBufferOutputStream(int, boolean) - Constructor for class org.apache.hadoop.hbase.io.ByteBufferOutputStream
 
ByteBufferOutputStream(ByteBuffer) - Constructor for class org.apache.hadoop.hbase.io.ByteBufferOutputStream
 
org.apache.hadoop.hbase.ByteBufferTag - Class in org.apache.hadoop.hbase
This is a Tag implementation in which value is backed by ByteBuffer
ByteBufferTag(ByteBuffer, int, int) - Constructor for class org.apache.hadoop.hbase.ByteBufferTag
 
org.apache.hadoop.hbase.util.ByteBufferUtils - Class in org.apache.hadoop.hbase.util
Deprecated.
This class will become IA.Private in HBase 3.0. Downstream folks shouldn't use it.
org.apache.hadoop.hbase.io.ByteBufferWriter - Interface in org.apache.hadoop.hbase.io
This interface marks a class to support writing ByteBuffers into it.
org.apache.hadoop.hbase.io.ByteBufferWriterDataOutputStream - Class in org.apache.hadoop.hbase.io
Our extension of DataOutputStream which implements ByteBufferWriter
ByteBufferWriterDataOutputStream(OutputStream) - Constructor for class org.apache.hadoop.hbase.io.ByteBufferWriterDataOutputStream
 
org.apache.hadoop.hbase.io.ByteBufferWriterOutputStream - Class in org.apache.hadoop.hbase.io
When deal with OutputStream which is not ByteBufferWriter type, wrap it with this class.
ByteBufferWriterOutputStream(OutputStream) - Constructor for class org.apache.hadoop.hbase.io.ByteBufferWriterOutputStream
 
ByteBufferWriterOutputStream(OutputStream, int) - Constructor for class org.apache.hadoop.hbase.io.ByteBufferWriterOutputStream
 
org.apache.hadoop.hbase.io.ByteBuffInputStream - Class in org.apache.hadoop.hbase.io
Not thread safe!
ByteBuffInputStream(ByteBuff) - Constructor for class org.apache.hadoop.hbase.io.ByteBuffInputStream
 
ByteBuffKeyValueDecoder(ByteBuff) - Constructor for class org.apache.hadoop.hbase.codec.KeyValueCodec.ByteBuffKeyValueDecoder
 
ByteBuffKeyValueDecoder(ByteBuff) - Constructor for class org.apache.hadoop.hbase.codec.KeyValueCodecWithTags.ByteBuffKeyValueDecoder
 
org.apache.hadoop.hbase.util.ByteRange - Interface in org.apache.hadoop.hbase.util
Lightweight, reusable class for specifying ranges of byte[]'s.
org.apache.hadoop.hbase.util.ByteRangeUtils - Class in org.apache.hadoop.hbase.util
Utility methods for working with ByteRange.
ByteRangeUtils() - Constructor for class org.apache.hadoop.hbase.util.ByteRangeUtils
 
bytes - Variable in class org.apache.hadoop.hbase.KeyValue
 
bytes - Variable in class org.apache.hadoop.hbase.util.AbstractByteRange
The array containing the bytes in this range.
org.apache.hadoop.hbase.util.Bytes - Class in org.apache.hadoop.hbase.util
Utility class that handles byte arrays, conversions to/from other types, comparisons, hash code generation, manufacturing keys for HashMaps or HashSets, and can be used as key in maps or trees.
Bytes() - Constructor for class org.apache.hadoop.hbase.util.Bytes
Create a zero-size sequence.
Bytes(byte[]) - Constructor for class org.apache.hadoop.hbase.util.Bytes
Create a Bytes using the byte array as the initial value.
Bytes(byte[], int, int) - Constructor for class org.apache.hadoop.hbase.util.Bytes
Set the value to a given byte range
Bytes(ByteString) - Constructor for class org.apache.hadoop.hbase.util.Bytes
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0.
Bytes(Bytes) - Constructor for class org.apache.hadoop.hbase.util.Bytes
Set the new Bytes to the contents of the passed ibw.
BYTES_COMPARATOR - Static variable in class org.apache.hadoop.hbase.util.Bytes
Pass this to TreeMaps where byte [] are keys.
BYTES_COMPARATOR - Static variable in class org.apache.hadoop.hbase.util.RegionSplitCalculator
 
BYTES_COPIED - Enum constant in enum org.apache.hadoop.hbase.snapshot.ExportSnapshot.Counter
 
BYTES_EXPECTED - Enum constant in enum org.apache.hadoop.hbase.snapshot.ExportSnapshot.Counter
 
BYTES_PER_CHECKSUM - Static variable in class org.apache.hadoop.hbase.HConstants
The name of the configuration parameter that specifies the number of bytes in a newly created checksum chunk.
BYTES_RAWCOMPARATOR - Static variable in class org.apache.hadoop.hbase.util.Bytes
Use comparing byte arrays, byte-by-byte
BYTES_SKIPPED - Enum constant in enum org.apache.hadoop.hbase.snapshot.ExportSnapshot.Counter
 
org.apache.hadoop.hbase.util.Bytes.ByteArrayComparator - Class in org.apache.hadoop.hbase.util
Byte array comparator class.
org.apache.hadoop.hbase.util.Bytes.RowEndKeyComparator - Class in org.apache.hadoop.hbase.util
A Bytes.ByteArrayComparator that treats the empty array as the largest value.
byteSize - Variable in class org.apache.hadoop.hbase.util.BloomFilterChunk
Bytes (B) in the array.
bytesToVint(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
Reads a zero-compressed encoded long from input buffer and returns it.
byteStringUncompressor - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractProtobufWALReader
 
BZIP2 - Enum constant in enum org.apache.hadoop.hbase.io.compress.Compression.Algorithm
 
BZIP2_CODEC_CLASS_DEFAULT - Static variable in class org.apache.hadoop.hbase.io.compress.Compression
 
BZIP2_CODEC_CLASS_KEY - Static variable in class org.apache.hadoop.hbase.io.compress.Compression
 

C

cache - Variable in class org.apache.hadoop.hbase.client.ClientScanner
 
CACHE_BLOCKS_ON_WRITE_KEY - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
Configuration key to cache data blocks on write.
CACHE_BLOOM_BLOCKS_ON_WRITE_KEY - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
Configuration key to cache compound bloom filter blocks on write.
CACHE_BLOOMS_ON_WRITE - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
CACHE_BLOOMS_ON_WRITE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
CACHE_COMPACTED_BLOCKS_ON_WRITE_KEY - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
Configuration key to cache blocks when a compacted file is written
CACHE_COMPACTED_BLOCKS_ON_WRITE_THRESHOLD_KEY - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
Configuration key to determine total size in bytes of compacted files beyond which we do not cache blocks on compaction
CACHE_DATA_BLOCKS_COMPRESSED_KEY - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
Configuration key to cache data blocks in compressed and/or encrypted format.
CACHE_DATA_IN_L1 - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
CACHE_DATA_ON_READ_KEY - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
Configuration key to cache data blocks on read.
CACHE_DATA_ON_WRITE - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
CACHE_DATA_ON_WRITE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
CACHE_FIXED_OVERHEAD - Static variable in class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache
 
CACHE_FIXED_OVERHEAD - Static variable in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
 
CACHE_INDEX_BLOCKS_ON_WRITE_KEY - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
Configuration key to cache leaf and intermediate-level index blocks on write.
CACHE_INDEX_ON_WRITE - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
CACHE_INDEX_ON_WRITE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
org.apache.hadoop.hbase.io.hfile.Cacheable - Interface in org.apache.hadoop.hbase.io.hfile
Cacheable is an interface that allows for an object to be cached.
org.apache.hadoop.hbase.io.hfile.CacheableDeserializer<T extends org.apache.hadoop.hbase.io.hfile.Cacheable> - Interface in org.apache.hadoop.hbase.io.hfile
Interface for a deserializer.
org.apache.hadoop.hbase.io.hfile.CacheableDeserializerIdManager - Class in org.apache.hadoop.hbase.io.hfile
This class is used to manage the identifiers for CacheableDeserializer.
CacheableDeserializerIdManager() - Constructor for class org.apache.hadoop.hbase.io.hfile.CacheableDeserializerIdManager
 
cacheBlock(BlockCacheKey, Cacheable) - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCache
Add block to cache (defaults to not in-memory).
cacheBlock(BlockCacheKey, Cacheable) - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
 
cacheBlock(BlockCacheKey, Cacheable) - Method in class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache
Cache the block with the specified name and buffer.
cacheBlock(BlockCacheKey, Cacheable) - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
Cache the block with the specified name and buffer.
cacheBlock(BlockCacheKey, Cacheable) - Method in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
 
cacheBlock(BlockCacheKey, Cacheable) - Method in class org.apache.hadoop.hbase.io.hfile.TinyLfuBlockCache
 
cacheBlock(BlockCacheKey, Cacheable, boolean) - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCache
Add block to cache.
cacheBlock(BlockCacheKey, Cacheable, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
 
cacheBlock(BlockCacheKey, Cacheable, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.InclusiveCombinedBlockCache
 
cacheBlock(BlockCacheKey, Cacheable, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.IndexOnlyLruBlockCache
Cache only index block with the specified name and buffer
cacheBlock(BlockCacheKey, Cacheable, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache
Cache the block with the specified name and buffer.
cacheBlock(BlockCacheKey, Cacheable, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
Cache the block with the specified name and buffer.
cacheBlock(BlockCacheKey, Cacheable, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
 
cacheBlock(BlockCacheKey, Cacheable, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.TinyLfuBlockCache
 
cacheBlock(BlockCacheKey, Cacheable, boolean, boolean) - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCache
Add block to cache.
cacheBlock(BlockCacheKey, Cacheable, boolean, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
 
cacheBlocks - Variable in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
 
cacheConf - Variable in class org.apache.hadoop.hbase.io.hfile.HFile.WriterFactory
 
cacheConf - Variable in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
Block cache configuration.
cacheConf - Variable in class org.apache.hadoop.hbase.io.hfile.HFileWriterImpl
Cache configuration for caching data on write.
org.apache.hadoop.hbase.io.hfile.CacheConfig - Class in org.apache.hadoop.hbase.io.hfile
Stores all of the cache objects and configuration for a single HFile.
CacheConfig(Configuration) - Constructor for class org.apache.hadoop.hbase.io.hfile.CacheConfig
Create a cache configuration using the specified configuration object and defaults for family level settings.
CacheConfig(Configuration, ColumnFamilyDescriptor, BlockCache, ByteBuffAllocator) - Constructor for class org.apache.hadoop.hbase.io.hfile.CacheConfig
Create a cache configuration using the specified configuration object and family descriptor.
CacheConfig(Configuration, BlockCache) - Constructor for class org.apache.hadoop.hbase.io.hfile.CacheConfig
 
CacheConfig(CacheConfig) - Constructor for class org.apache.hadoop.hbase.io.hfile.CacheConfig
Constructs a cache configuration copied from the specified configuration.
org.apache.hadoop.hbase.io.hfile.CachedBlock - Interface in org.apache.hadoop.hbase.io.hfile
 
org.apache.hadoop.hbase.master.CachedClusterId - Class in org.apache.hadoop.hbase.master
Caches the cluster ID of the cluster.
CachedClusterId(Server, Configuration) - Constructor for class org.apache.hadoop.hbase.master.CachedClusterId
 
org.apache.hadoop.hbase.mob.CachedMobFile - Class in org.apache.hadoop.hbase.mob
Cached mob file.
CachedMobFile(HStoreFile) - Constructor for class org.apache.hadoop.hbase.mob.CachedMobFile
 
org.apache.hadoop.hbase.CacheEvictionStats - Class in org.apache.hadoop.hbase
 
org.apache.hadoop.hbase.CacheEvictionStatsAggregator - Class in org.apache.hadoop.hbase
Used to merge CacheEvictionStats.
CacheEvictionStatsAggregator() - Constructor for class org.apache.hadoop.hbase.CacheEvictionStatsAggregator
 
org.apache.hadoop.hbase.CacheEvictionStatsBuilder - Class in org.apache.hadoop.hbase
 
cacheIfCompactionsOff() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
 
cacheLocation(TableName, RegionLocations) - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
 
cacheLocation(TableName, RegionLocations) - Method in class org.apache.hadoop.hbase.client.ConnectionImplementation
Put a newly discovered HRegionLocation into the cache.
cacheLocation(TableName, RegionLocations) - Method in class org.apache.hadoop.hbase.client.MetaCache
Put a newly discovered HRegionLocation into the cache.
cacheLocation(TableName, ServerName, HRegionLocation) - Method in class org.apache.hadoop.hbase.client.MetaCache
Put a newly discovered HRegionLocation into the cache.
org.apache.hadoop.hbase.io.hfile.CacheStats - Class in org.apache.hadoop.hbase.io.hfile
Class that implements cache metrics.
CacheStats(String) - Constructor for class org.apache.hadoop.hbase.io.hfile.CacheStats
 
CacheStats(String, int) - Constructor for class org.apache.hadoop.hbase.io.hfile.CacheStats
 
cacheTableDescriptor() - Method in class org.apache.hadoop.hbase.master.HMaster
 
cacheTableDescriptor() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
caching - Variable in class org.apache.hadoop.hbase.client.ClientScanner
 
calcCoverage() - Method in class org.apache.hadoop.hbase.util.RegionSplitCalculator
Generates a coverage multimap from split key to Regions that start with the split key.
calcIndexKey(byte[], byte[]) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
Deprecated.
 
calcPercentage(long, long) - Static method in class org.apache.hadoop.hbase.util.JSONMetricUtil
 
calculateAutoBalancedSplits(List<InputSplit>, long) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
Calculates the number of MapReduce input splits for the map tasks.
calculateMutationSize(Mutation) - Static method in class org.apache.hadoop.hbase.quotas.QuotaUtil
 
calculateResultSize(List<Result>) - Static method in class org.apache.hadoop.hbase.quotas.QuotaUtil
 
calculateResultSize(Result) - Static method in class org.apache.hadoop.hbase.quotas.QuotaUtil
 
calculateTheClosestNextRowKeyForPrefix(byte[]) - Static method in class org.apache.hadoop.hbase.client.ClientUtil
When scanning for a prefix the scan should stop immediately after the the last row that has the specified prefix.
CALCULATION_LOCK - Enum constant in enum org.apache.hadoop.hbase.regionserver.ReadPointCalculationLock.LockType
 
call() - Method in class org.apache.hadoop.hbase.client.example.MultiThreadedClientExample.ReadExampleCallable
 
call() - Method in class org.apache.hadoop.hbase.client.example.MultiThreadedClientExample.SingleWriteExampleCallable
 
call() - Method in class org.apache.hadoop.hbase.client.example.MultiThreadedClientExample.WriteExampleCallable
 
call(int) - Method in class org.apache.hadoop.hbase.client.RegionAdminServiceCallable
Override that changes Exception from Exception to IOException.
call(int) - Method in class org.apache.hadoop.hbase.client.RegionServerCallable
Override that changes call Exception from Exception to IOException.
call(int) - Method in interface org.apache.hadoop.hbase.client.RetryingCallable
Computes a result, or throws an exception if unable to do so.
call(int) - Method in class org.apache.hadoop.hbase.client.RpcRetryingCallerWithReadReplicas
Algo: - we put the query into the execution pool.
call(Class<T>, T, String, Class[], Object[]) - Static method in class org.apache.hadoop.hbase.util.Methods
 
call(Callable<T>) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
Contain ServiceException inside here.
call(O) - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost.ObserverOperationWithoutResult
 
call(O) - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost.ObserverOperationWithResult
 
call(AbstractRpcBasedConnectionRegistry.Callable<T>, Predicate<T>, String) - Method in class org.apache.hadoop.hbase.client.RpcConnectionRegistry
 
call(HBaseRpcController) - Method in class org.apache.hadoop.hbase.client.FlushRegionCallable
 
call(HBaseRpcController) - Method in class org.apache.hadoop.hbase.client.RegionAdminServiceCallable
Run RPC call.
call(HBaseRpcController, AdminProtos.AdminService.Interface) - Method in interface org.apache.hadoop.hbase.client.AsyncAdminRequestRetryingCaller.Callable
 
call(HBaseRpcController, ClientProtos.ClientService.Interface) - Method in interface org.apache.hadoop.hbase.client.AsyncServerRequestRpcRetryingCaller.Callable
 
call(HBaseRpcController, MasterProtos.MasterService.Interface) - Method in interface org.apache.hadoop.hbase.client.AsyncMasterRequestRpcRetryingCaller.Callable
 
call(RpcCall, MonitoredRPCHandler) - Method in class org.apache.hadoop.hbase.ipc.RpcServer
This is a server side method, which is invoked over RPC.
call(RpcCall, MonitoredRPCHandler) - Method in interface org.apache.hadoop.hbase.ipc.RpcServerInterface
 
call(BlockingService, Descriptors.MethodDescriptor, Message, CellScanner, long, MonitoredRPCHandler) - Method in class org.apache.hadoop.hbase.ipc.NettyRpcServer
 
call(BlockingService, Descriptors.MethodDescriptor, Message, CellScanner, long, MonitoredRPCHandler) - Method in interface org.apache.hadoop.hbase.ipc.RpcServerInterface
Deprecated.
As of release 1.3, this will be removed in HBase 3.0
call(BlockingService, Descriptors.MethodDescriptor, Message, CellScanner, long, MonitoredRPCHandler) - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcServer
Deprecated.
 
call(BlockingService, Descriptors.MethodDescriptor, Message, CellScanner, long, MonitoredRPCHandler, long, int) - Method in class org.apache.hadoop.hbase.ipc.NettyRpcServer
 
call(BlockingService, Descriptors.MethodDescriptor, Message, CellScanner, long, MonitoredRPCHandler, long, int) - Method in interface org.apache.hadoop.hbase.ipc.RpcServerInterface
Deprecated.
As of release 2.0, this will be removed in HBase 3.0
call(BlockingService, Descriptors.MethodDescriptor, Message, CellScanner, long, MonitoredRPCHandler, long, int) - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcServer
Deprecated.
 
call(S, RpcController, RpcCallback<R>) - Method in interface org.apache.hadoop.hbase.client.ServiceCaller
Represent the actual protobuf rpc call.
CALL_QUEUE_CODEL_DEFAULT_INTERVAL - Static variable in class org.apache.hadoop.hbase.ipc.RpcExecutor
 
CALL_QUEUE_CODEL_DEFAULT_LIFO_THRESHOLD - Static variable in class org.apache.hadoop.hbase.ipc.RpcExecutor
 
CALL_QUEUE_CODEL_DEFAULT_TARGET_DELAY - Static variable in class org.apache.hadoop.hbase.ipc.RpcExecutor
 
CALL_QUEUE_CODEL_INTERVAL - Static variable in class org.apache.hadoop.hbase.ipc.RpcExecutor
 
CALL_QUEUE_CODEL_LIFO_THRESHOLD - Static variable in class org.apache.hadoop.hbase.ipc.RpcExecutor
 
CALL_QUEUE_CODEL_TARGET_DELAY - Static variable in class org.apache.hadoop.hbase.ipc.RpcExecutor
 
CALL_QUEUE_HANDLER_FACTOR_CONF_KEY - Static variable in class org.apache.hadoop.hbase.ipc.RpcExecutor
 
CALL_QUEUE_LEN_KEY - Static variable in interface org.apache.hadoop.hbase.thrift.MetricsThriftServerSource
 
CALL_QUEUE_QUEUE_BALANCER_CLASS - Static variable in class org.apache.hadoop.hbase.ipc.RpcExecutor
 
CALL_QUEUE_QUEUE_BALANCER_CLASS_DEFAULT - Static variable in class org.apache.hadoop.hbase.ipc.RpcExecutor
 
CALL_QUEUE_READ_SHARE_CONF_KEY - Static variable in class org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
 
CALL_QUEUE_SCAN_SHARE_CONF_KEY - Static variable in class org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
 
CALL_QUEUE_TOO_BIG_EXCEPTION - Static variable in class org.apache.hadoop.hbase.ipc.RpcServer
 
CALL_QUEUE_TYPE_CODEL_CONF_VALUE - Static variable in class org.apache.hadoop.hbase.ipc.RpcExecutor
The default, 'fifo', has the least friction but is dumb.
CALL_QUEUE_TYPE_CONF_DEFAULT - Static variable in class org.apache.hadoop.hbase.ipc.RpcExecutor
 
CALL_QUEUE_TYPE_CONF_KEY - Static variable in class org.apache.hadoop.hbase.ipc.RpcExecutor
 
CALL_QUEUE_TYPE_DEADLINE_CONF_VALUE - Static variable in class org.apache.hadoop.hbase.ipc.RpcExecutor
 
CALL_QUEUE_TYPE_FIFO_CONF_VALUE - Static variable in class org.apache.hadoop.hbase.ipc.RpcExecutor
 
CALL_QUEUE_TYPE_PLUGGABLE_CONF_VALUE - Static variable in class org.apache.hadoop.hbase.ipc.RpcExecutor
 
callable - Variable in class org.apache.hadoop.hbase.client.ClientScanner
 
callBlockingMethod(Descriptors.MethodDescriptor, RpcController, Message, Message) - Method in class org.apache.hadoop.hbase.ipc.AbstractRpcClient.BlockingRpcChannelImplementation
 
org.apache.hadoop.hbase.ipc.CallCancelledException - Exception in org.apache.hadoop.hbase.ipc
Client side call cancelled.
CallCancelledException(String) - Constructor for exception org.apache.hadoop.hbase.ipc.CallCancelledException
 
callDroppedException() - Method in interface org.apache.hadoop.hbase.metrics.ExceptionTrackingSource
 
callDroppedException() - Method in class org.apache.hadoop.hbase.metrics.ExceptionTrackingSourceImpl
 
org.apache.hadoop.hbase.CallDroppedException - Exception in org.apache.hadoop.hbase
Returned to the clients when their request was discarded due to server being overloaded.
CallDroppedException() - Constructor for exception org.apache.hadoop.hbase.CallDroppedException
 
CallDroppedException(String) - Constructor for exception org.apache.hadoop.hbase.CallDroppedException
 
caller - Variable in class org.apache.hadoop.hbase.client.ClientScanner
 
org.apache.hadoop.hbase.ipc.CallerDisconnectedException - Exception in org.apache.hadoop.hbase.ipc
Exception indicating that the remote host making this IPC lost its IPC connection.
CallerDisconnectedException(String) - Constructor for exception org.apache.hadoop.hbase.ipc.CallerDisconnectedException
 
callMethod(Descriptors.MethodDescriptor, RpcController, Message, Message, RpcCallback<Message>) - Method in class org.apache.hadoop.hbase.client.RegionServerCoprocessorRpcChannelImpl
 
callMethod(Descriptors.MethodDescriptor, RpcController, Message, Message, RpcCallback<Message>) - Method in class org.apache.hadoop.hbase.ipc.AbstractRpcClient.RpcChannelImplementation
 
org.apache.hadoop.hbase.thrift.CallQueue - Class in org.apache.hadoop.hbase.thrift
A BlockingQueue reports waiting time in queue and queue length to ThriftMetrics.
CallQueue(BlockingQueue<CallQueue.Call>, ThriftMetrics) - Constructor for class org.apache.hadoop.hbase.thrift.CallQueue
 
org.apache.hadoop.hbase.thrift.CallQueue.Call - Class in org.apache.hadoop.hbase.thrift
 
org.apache.hadoop.hbase.ipc.CallQueueInfo - Class in org.apache.hadoop.hbase.ipc
 
callQueueSizeInBytes - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
This is a running count of the size in bytes of all outstanding calls whether currently executing or queued waiting to be run.
callQueueTooBigException() - Method in interface org.apache.hadoop.hbase.metrics.ExceptionTrackingSource
 
callQueueTooBigException() - Method in class org.apache.hadoop.hbase.metrics.ExceptionTrackingSourceImpl
 
org.apache.hadoop.hbase.CallQueueTooBigException - Exception in org.apache.hadoop.hbase
Returned to clients when their request was dropped because the call queue was too big to accept a new call.
CallQueueTooBigException() - Constructor for exception org.apache.hadoop.hbase.CallQueueTooBigException
 
CallQueueTooBigException(String) - Constructor for exception org.apache.hadoop.hbase.CallQueueTooBigException
 
org.apache.hadoop.hbase.ipc.CallRunner - Class in org.apache.hadoop.hbase.ipc
The request processing logic, which is usually executed in thread pools provided by an RpcScheduler.
CallStats() - Constructor for class org.apache.hadoop.hbase.client.MetricsConnection.CallStats
 
callTimedOut() - Method in interface org.apache.hadoop.hbase.metrics.ExceptionTrackingSource
 
callTimedOut() - Method in class org.apache.hadoop.hbase.metrics.ExceptionTrackingSourceImpl
 
org.apache.hadoop.hbase.ipc.CallTimeoutException - Exception in org.apache.hadoop.hbase.ipc
Client-side call timeout
CallTimeoutException(String) - Constructor for exception org.apache.hadoop.hbase.ipc.CallTimeoutException
 
CallTimeoutException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.ipc.CallTimeoutException
CallTimeoutException with cause
callWithoutRetries(RetryingCallable<T>, int) - Method in interface org.apache.hadoop.hbase.client.RpcRetryingCaller
Call the server once only.
callWithoutRetries(RetryingCallable<T>, int) - Method in class org.apache.hadoop.hbase.client.RpcRetryingCallerImpl
 
callWithRetries(RetryingCallable<T>, int) - Method in interface org.apache.hadoop.hbase.client.RpcRetryingCaller
Retries if invocation fails.
callWithRetries(RetryingCallable<T>, int) - Method in class org.apache.hadoop.hbase.client.RpcRetryingCallerImpl
 
canBeFlattened() - Method in class org.apache.hadoop.hbase.regionserver.CellArrayImmutableSegment
 
canBeFlattened() - Method in class org.apache.hadoop.hbase.regionserver.CellChunkImmutableSegment
 
canBeFlattened() - Method in class org.apache.hadoop.hbase.regionserver.CompositeImmutableSegment
 
canBeFlattened() - Method in class org.apache.hadoop.hbase.regionserver.CSLMImmutableSegment
 
canBeFlattened() - Method in class org.apache.hadoop.hbase.regionserver.ImmutableSegment
 
cancel() - Method in interface org.apache.hadoop.hbase.client.RpcRetryingCaller
 
cancel() - Method in class org.apache.hadoop.hbase.client.RpcRetryingCallerImpl
 
cancel() - Method in class org.apache.hadoop.hbase.ScheduledChore
 
cancel(boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture
 
cancel(boolean) - Method in class org.apache.hadoop.hbase.JitterScheduledThreadPoolExecutorImpl.JitteredRunnableScheduledFuture
 
cancel(boolean) - Method in class org.apache.hadoop.hbase.ScheduledChore
 
cancel(String) - Method in interface org.apache.hadoop.hbase.backup.BackupCopyJob
Cancel copy job
cancel(String) - Method in interface org.apache.hadoop.hbase.master.SnapshotSentinel
Actively cancel a running snapshot.
cancel(Path) - Static method in class org.apache.hadoop.hbase.io.hfile.PrefetchExecutor
 
CANCEL - Enum constant in enum org.apache.hadoop.hbase.backup.BackupRestoreConstants.BackupCommand
 
org.apache.hadoop.hbase.util.CancelableProgressable - Interface in org.apache.hadoop.hbase.util
Similar interface as Progressable but returns a boolean to support canceling the operation.
cancelAll() - Method in class org.apache.hadoop.hbase.client.ResultBoundedCompletionService
 
cancelAll(boolean) - Method in class org.apache.hadoop.hbase.util.BoundedCompletionService
 
cancelConnections(ServerName) - Method in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
Interrupt the connections to the given ip:port server.
cancelConnections(ServerName) - Method in interface org.apache.hadoop.hbase.ipc.RpcClient
Interrupt the connections to the given server.
cancelLease(String) - Method in class org.apache.hadoop.hbase.regionserver.LeaseManager
Client explicitly cancels a lease.
cancelRequestedCompaction(CompactionContext) - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
cancelTimer() - Method in class org.apache.hadoop.hbase.hbtop.screen.AbstractScreenView
 
cancelTimer() - Method in class org.apache.hadoop.hbase.hbtop.screen.Screen
 
canCreateBaseZNode() - Method in class org.apache.hadoop.hbase.master.HMaster
 
canCreateBaseZNode() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
CANNOT_FLUSH - Enum constant in enum org.apache.hadoop.hbase.regionserver.HRegion.FlushResult.Result
 
CANNOT_FLUSH_MEMSTORE_EMPTY - Enum constant in enum org.apache.hadoop.hbase.regionserver.HRegion.FlushResult.Result
 
canPlaceFavoredNodes() - Method in class org.apache.hadoop.hbase.favored.FavoredNodeAssignmentHelper
 
canQueue() - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
 
org.apache.hadoop.hbase.io.compress.CanReinit - Interface in org.apache.hadoop.hbase.io.compress
This is a marker interface that indicates if a compressor or decompressor type can support reinitialization via reinit(Configuration conf).
canReplicateToSameCluster() - Method in class org.apache.hadoop.hbase.replication.BaseReplicationEndpoint
 
canReplicateToSameCluster() - Method in interface org.apache.hadoop.hbase.replication.ReplicationEndpoint
Whether or not, the replication endpoint can replicate to it's source cluster with the same UUID
canReplicateToSameCluster() - Method in class org.apache.hadoop.hbase.replication.VerifyWALEntriesReplicationEndpoint
 
canSplit() - Method in class org.apache.hadoop.hbase.regionserver.DisabledRegionSplitPolicy
 
canSplit() - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
canSplit() - Method in class org.apache.hadoop.hbase.regionserver.RegionSplitPolicy
Returns true if the specified region can be split.
canSplit() - Method in interface org.apache.hadoop.hbase.regionserver.Store
Returns whether this store is splittable, i.e., no reference file in this store.
canTakeRow(HRegionLocation, Row) - Method in interface org.apache.hadoop.hbase.client.RequestController.Checker
Checks the data whether it is valid to submit.
canUpdateTableDescriptor() - Method in class org.apache.hadoop.hbase.master.HMaster
 
canUpdateTableDescriptor() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
canUserModifyUI(HttpServletRequest, ServletContext, Configuration) - Static method in class org.apache.hadoop.hbase.http.InfoServer
Returns true if and only if UI authentication (spnego) is enabled, UI authorization is enabled, and the requesting user is defined as an administrator.
capacity() - Method in class org.apache.hadoop.hbase.nio.ByteBuff
Returns the total capacity of this ByteBuff.
capacity() - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
Returns the total capacity of this MultiByteBuffer.
capacity() - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
 
carryForwardTags(List<Tag>, Cell) - Static method in class org.apache.hadoop.hbase.TagUtil
Add to tagsOrNull any Tags cell is carrying or null if none.
carryForwardTags(Cell) - Static method in class org.apache.hadoop.hbase.TagUtil
Returns A List<Tag> of any Tags found in cell else null.
carryForwardTTLTag(List<Tag>, long) - Static method in class org.apache.hadoop.hbase.TagUtil
Returns Carry forward the TTL tag.
cast(Class<?>) - Static method in class org.apache.hadoop.hbase.util.Classes
 
castToCellType(S) - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
The response message comes as type S.
castToReturnType(T) - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
provides casting opportunity between the data types.
CATALOG_FAMILY - Static variable in class org.apache.hadoop.hbase.HConstants
The catalog family
CATALOG_FAMILY_STR - Static variable in class org.apache.hadoop.hbase.HConstants
The catalog family as a string
catalogJanitorSwitch(boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
Enable/Disable the catalog janitor/
catalogJanitorSwitch(boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Turn the catalog janitor on/off.
catalogJanitorSwitch(boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
org.apache.hadoop.hbase.CatalogReplicaMode - Enum in org.apache.hadoop.hbase
There are two modes with catalog replica support.
cConnection - Variable in class org.apache.hadoop.hbase.client.RpcRetryingCallerWithReadReplicas
 
ceiling(Cell) - Method in class org.apache.hadoop.hbase.regionserver.CellSet
 
ceilingEntry(K) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
 
ceilingEntry(Cell) - Method in class org.apache.hadoop.hbase.regionserver.CellFlatMap
 
ceilingKey(K) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
 
ceilingKey(Cell) - Method in class org.apache.hadoop.hbase.regionserver.CellFlatMap
 
org.apache.hadoop.hbase.hbtop.terminal.impl.Cell - Class in org.apache.hadoop.hbase.hbtop.terminal.impl
Represents a single text cell of the terminal.
org.apache.hadoop.hbase.Cell - Interface in org.apache.hadoop.hbase
The unit of storage in HBase consisting of the following fields:
Cell() - Constructor for class org.apache.hadoop.hbase.hbtop.terminal.impl.Cell
 
CELL_ARRAY_MAP - Static variable in class org.apache.hadoop.hbase.util.ClassSize
Overhead for CellArrayMap
CELL_ARRAY_MAP_ENTRY - Static variable in class org.apache.hadoop.hbase.util.ClassSize
Overhead for Cell Array Entry
CELL_AUTHORIZATION - Enum constant in enum org.apache.hadoop.hbase.client.security.SecurityCapability
 
CELL_CHUNK_MAP - Static variable in class org.apache.hadoop.hbase.util.ClassSize
Overhead for CellChunkMap
CELL_CHUNK_MAP_ENTRY - Static variable in class org.apache.hadoop.hbase.util.ClassSize
Overhead for Cell Chunk Map Entry
CELL_FLAT_MAP - Static variable in class org.apache.hadoop.hbase.util.ClassSize
Overhead for CellFlatMap
CELL_NOT_BASED_ON_CHUNK - Static variable in interface org.apache.hadoop.hbase.ExtendedCell
 
CELL_SET - Static variable in class org.apache.hadoop.hbase.util.ClassSize
Overhead for CellSkipListSet
CELL_TTL_COLUMN_SPEC - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
 
CELL_VISIBILITY - Enum constant in enum org.apache.hadoop.hbase.client.security.SecurityCapability
 
CELL_VISIBILITY_COLUMN_SPEC - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
 
org.apache.hadoop.hbase.Cell.Type - Enum in org.apache.hadoop.hbase
The valid types for user to build the cell.
org.apache.hadoop.hbase.regionserver.CellArrayImmutableSegment - Class in org.apache.hadoop.hbase.regionserver
CellArrayImmutableSegment extends the API supported by a Segment, and ImmutableSegment.
CellArrayImmutableSegment(CellComparator, MemStoreSegmentsIterator, MemStoreLAB, int, MemStoreCompactionStrategy.Action) - Constructor for class org.apache.hadoop.hbase.regionserver.CellArrayImmutableSegment
------------------------------------------------------------------------ C-tor to be used when new CellArrayImmutableSegment is a result of compaction of a list of older ImmutableSegments.
CellArrayImmutableSegment(CSLMImmutableSegment, MemStoreSizing, MemStoreCompactionStrategy.Action) - Constructor for class org.apache.hadoop.hbase.regionserver.CellArrayImmutableSegment
------------------------------------------------------------------------ C-tor to be used when new CellChunkImmutableSegment is built as a result of flattening of CSLMImmutableSegment The given iterator returns the Cells that "survived" the compaction.
org.apache.hadoop.hbase.regionserver.CellArrayMap - Class in org.apache.hadoop.hbase.regionserver
CellArrayMap is a simple array of Cells and cannot be allocated off-heap.
CellArrayMap(Comparator<? super Cell>, Cell[], int, int, boolean) - Constructor for class org.apache.hadoop.hbase.regionserver.CellArrayMap
 
cellBlockBuilder - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
cellBlockBuilder - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
 
cellBlockBuilder - Variable in class org.apache.hadoop.hbase.ipc.ServerCall
 
cellBlockStream - Variable in class org.apache.hadoop.hbase.ipc.ServerCall
 
org.apache.hadoop.hbase.CellBuilder - Interface in org.apache.hadoop.hbase
Use CellBuilderFactory to get CellBuilder instance.
org.apache.hadoop.hbase.CellBuilderFactory - Class in org.apache.hadoop.hbase
Create a CellBuilder instance.
org.apache.hadoop.hbase.CellBuilderType - Enum in org.apache.hadoop.hbase
Used by CellBuilderFactory and ExtendedCellBuilderFactory.
org.apache.hadoop.hbase.regionserver.CellChunkImmutableSegment - Class in org.apache.hadoop.hbase.regionserver
CellChunkImmutableSegment extends the API supported by a Segment, and ImmutableSegment.
CellChunkImmutableSegment(CellComparator, MemStoreSegmentsIterator, MemStoreLAB, int, MemStoreCompactionStrategy.Action) - Constructor for class org.apache.hadoop.hbase.regionserver.CellChunkImmutableSegment
------------------------------------------------------------------------ C-tor to be used when new CellChunkImmutableSegment is built as a result of compaction/merge of a list of older ImmutableSegments.
CellChunkImmutableSegment(CSLMImmutableSegment, MemStoreSizing, MemStoreCompactionStrategy.Action) - Constructor for class org.apache.hadoop.hbase.regionserver.CellChunkImmutableSegment
------------------------------------------------------------------------ C-tor to be used when new CellChunkImmutableSegment is built as a result of flattening of CSLMImmutableSegment The given iterator returns the Cells that "survived" the compaction.
org.apache.hadoop.hbase.regionserver.CellChunkMap - Class in org.apache.hadoop.hbase.regionserver
CellChunkMap is an array of serialized representations of Cell (pointing to Chunks with full Cell data) and can be allocated both off-heap and on-heap.
CellChunkMap(Comparator<? super Cell>, Chunk[], int, int, boolean) - Constructor for class org.apache.hadoop.hbase.regionserver.CellChunkMap
C-tor for creating CellChunkMap from existing Chunk array, which must be ordered (decreasingly or increasingly according to parameter "descending")
org.apache.hadoop.hbase.codec.CellCodec - Class in org.apache.hadoop.hbase.codec
Basic Cell codec that just writes out all the individual elements of a Cell.
CellCodec() - Constructor for class org.apache.hadoop.hbase.codec.CellCodec
 
org.apache.hadoop.hbase.codec.CellCodecWithTags - Class in org.apache.hadoop.hbase.codec
Basic Cell codec that just writes out all the individual elements of a Cell including the tags.
CellCodecWithTags() - Constructor for class org.apache.hadoop.hbase.codec.CellCodecWithTags
 
CellComparator - Interface in org.apache.hadoop.hbase
Comparator for comparing cells and has some specialized methods that allows comparing individual cell components like row, family, qualifier and timestamp
org.apache.hadoop.hbase.CellComparatorImpl - Class in org.apache.hadoop.hbase
Compare two HBase cells.
CellComparatorImpl() - Constructor for class org.apache.hadoop.hbase.CellComparatorImpl
 
org.apache.hadoop.hbase.mapreduce.CellCounter - Class in org.apache.hadoop.hbase.mapreduce
A job with a a map and reduce phase to count cells in a table.
CellCounter() - Constructor for class org.apache.hadoop.hbase.mapreduce.CellCounter
 
org.apache.hadoop.hbase.mapreduce.CellCreator - Class in org.apache.hadoop.hbase.mapreduce
Facade to create Cells for HFileOutputFormat.
CellCreator(Configuration) - Constructor for class org.apache.hadoop.hbase.mapreduce.CellCreator
 
cellDecoder - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractProtobufWALReader
 
CellDeserializer() - Constructor for class org.apache.hadoop.hbase.mapreduce.CellSerialization.CellDeserializer
 
cellEncoder - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractProtobufLogWriter
 
org.apache.hadoop.hbase.regionserver.CellFlatMap - Class in org.apache.hadoop.hbase.regionserver
CellFlatMap stores a constant number of elements and is immutable after creation stage.
CellFlatMap(Comparator<? super Cell>, int, int, boolean) - Constructor for class org.apache.hadoop.hbase.regionserver.CellFlatMap
 
cellFromHBase(Cell) - Static method in class org.apache.hadoop.hbase.thrift.ThriftUtilities
This utility method creates a list of Thrift TCell "struct" based on an Hbase Cell object.
cellFromHBase(Cell[]) - Static method in class org.apache.hadoop.hbase.thrift.ThriftUtilities
This utility method creates a list of Thrift TCell "struct" based on an Hbase Cell array.
org.apache.hadoop.hbase.util.CellHashKey - Class in org.apache.hadoop.hbase.util
Extracts the byte for the hash calculation from the given cell
CellHashKey(Cell) - Constructor for class org.apache.hadoop.hbase.util.CellHashKey
 
CellImporter() - Constructor for class org.apache.hadoop.hbase.mapreduce.Import.CellImporter
 
org.apache.hadoop.hbase.io.CellOutputStream - Interface in org.apache.hadoop.hbase.io
Accepts a stream of Cells.
CellReducer() - Constructor for class org.apache.hadoop.hbase.mapreduce.Import.CellReducer
 
CELLS_COUNT_COMPACTED_FROM_MOB - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
CELLS_COUNT_COMPACTED_FROM_MOB_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
CELLS_COUNT_COMPACTED_TO_MOB - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
CELLS_COUNT_COMPACTED_TO_MOB_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
CELLS_READ - Enum constant in enum org.apache.hadoop.hbase.mapreduce.WALPlayer.Counter
 
CELLS_SIZE_COMPACTED_FROM_MOB - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
CELLS_SIZE_COMPACTED_FROM_MOB_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
CELLS_SIZE_COMPACTED_TO_MOB - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
CELLS_SIZE_COMPACTED_TO_MOB_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
CELLS_WRITTEN - Enum constant in enum org.apache.hadoop.hbase.mapreduce.WALPlayer.Counter
 
org.apache.hadoop.hbase.CellScannable - Interface in org.apache.hadoop.hbase
Implementer can return a CellScanner over its Cell content.
cellScanner - Variable in class org.apache.hadoop.hbase.ipc.ServerCall
 
cellScanner() - Method in interface org.apache.hadoop.hbase.CellScannable
Returns A CellScanner over the contained Cells
cellScanner() - Method in class org.apache.hadoop.hbase.client.Mutation
 
cellScanner() - Method in class org.apache.hadoop.hbase.client.Result
 
cellScanner() - Method in class org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
 
cellScanner() - Method in class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
Returns One-shot cell scanner (you cannot back it up and restart)
org.apache.hadoop.hbase.CellScanner - Interface in org.apache.hadoop.hbase
An interface for iterating through a sequence of cells.
org.apache.hadoop.hbase.ipc.CellScannerButNoCodecException - Exception in org.apache.hadoop.hbase.ipc
Thrown if a cellscanner but no codec to encode it with.
CellScannerButNoCodecException() - Constructor for exception org.apache.hadoop.hbase.ipc.CellScannerButNoCodecException
 
org.apache.hadoop.hbase.mapreduce.CellSerialization - Class in org.apache.hadoop.hbase.mapreduce
Use to specify the type of serialization for the mappers and reducers
CellSerialization() - Constructor for class org.apache.hadoop.hbase.mapreduce.CellSerialization
 
org.apache.hadoop.hbase.mapreduce.CellSerialization.CellDeserializer - Class in org.apache.hadoop.hbase.mapreduce
 
org.apache.hadoop.hbase.mapreduce.CellSerialization.CellSerializer - Class in org.apache.hadoop.hbase.mapreduce
 
CellSerializer() - Constructor for class org.apache.hadoop.hbase.mapreduce.CellSerialization.CellSerializer
 
org.apache.hadoop.hbase.regionserver.CellSet - Class in org.apache.hadoop.hbase.regionserver
A Set of Cells, where an add will overwrite the entry if already exists in the set.
CellSet(CellComparator) - Constructor for class org.apache.hadoop.hbase.regionserver.CellSet
 
CellSetModelStream() - Constructor for class org.apache.hadoop.hbase.rest.TableScanResource.CellSetModelStream
 
CellSetModelStream(ArrayList<RowModel>) - Constructor for class org.apache.hadoop.hbase.rest.TableScanResource.CellSetModelStream
 
org.apache.hadoop.hbase.regionserver.CellSink - Interface in org.apache.hadoop.hbase.regionserver
A sink of cells that allows appending cells to the Writers that implement it.
CellSortImporter() - Constructor for class org.apache.hadoop.hbase.mapreduce.Import.CellSortImporter
 
org.apache.hadoop.hbase.mapreduce.CellSortReducer - Class in org.apache.hadoop.hbase.mapreduce
Emits sorted Cells.
CellSortReducer() - Constructor for class org.apache.hadoop.hbase.mapreduce.CellSortReducer
 
org.apache.hadoop.hbase.CellUtil - Class in org.apache.hadoop.hbase
Utility methods helpful for slinging Cell instances.
cellVisibilityExpr - Variable in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
 
CellWritableComparable() - Constructor for class org.apache.hadoop.hbase.mapreduce.Import.CellWritableComparable
 
CellWritableComparable(Cell) - Constructor for class org.apache.hadoop.hbase.mapreduce.Import.CellWritableComparable
 
CellWritableComparablePartitioner() - Constructor for class org.apache.hadoop.hbase.mapreduce.Import.CellWritableComparablePartitioner
 
CellWritableComparator() - Constructor for class org.apache.hadoop.hbase.mapreduce.Import.CellWritableComparable.CellWritableComparator
 
CF_RENAME_PROP - Static variable in class org.apache.hadoop.hbase.mapreduce.Import
 
cfName - Variable in class org.apache.hadoop.hbase.regionserver.MemStoreCompactionStrategy
 
CFNAME - Static variable in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Deprecated.
 
org.apache.hadoop.hbase.replication.ChainWALEntryFilter - Class in org.apache.hadoop.hbase.replication
A WALEntryFilter which contains multiple filters and applies them in chain order
ChainWALEntryFilter(List<WALEntryFilter>) - Constructor for class org.apache.hadoop.hbase.replication.ChainWALEntryFilter
 
ChainWALEntryFilter(WALEntryFilter...) - Constructor for class org.apache.hadoop.hbase.replication.ChainWALEntryFilter
 
chance - Variable in class org.apache.hadoop.hbase.filter.RandomRowFilter
 
org.apache.hadoop.hbase.regionserver.ChangedReadersObserver - Interface in org.apache.hadoop.hbase.regionserver
If set of MapFile.Readers in Store change, implementors are notified.
CHANNEL_WRITABLE_FATAL_WATERMARK_KEY - Static variable in class org.apache.hadoop.hbase.ipc.NettyRpcServer
Fatal watermark for pending outbound bytes of a single netty channel.
CHANNEL_WRITABLE_HIGH_WATERMARK_KEY - Static variable in class org.apache.hadoop.hbase.ipc.NettyRpcServer
High watermark for pending outbound bytes of a single netty channel.
CHANNEL_WRITABLE_LOW_WATERMARK_KEY - Static variable in class org.apache.hadoop.hbase.ipc.NettyRpcServer
Low watermark for pending outbound bytes of a single netty channel.
channelClass - Variable in class org.apache.hadoop.hbase.wal.AsyncFSWALProvider
Protected visibility for used in tests.
channelInactive(ChannelHandlerContext) - Method in class org.apache.hadoop.hbase.security.NettyHBaseSaslRpcClientHandler
 
channelRead(ReadableByteChannel, ByteBuffer) - Method in class org.apache.hadoop.hbase.ipc.RpcServer
channelRead0(ChannelHandlerContext, ByteBuf) - Method in class org.apache.hadoop.hbase.security.NettyHBaseRpcConnectionHeaderHandler
 
channelRead0(ChannelHandlerContext, ByteBuf) - Method in class org.apache.hadoop.hbase.security.NettyHBaseSaslRpcClientHandler
 
channelRead0(ChannelHandlerContext, ByteBuf) - Method in class org.apache.hadoop.hbase.security.SaslUnwrapHandler
 
channelWritabilityChanged(ChannelHandlerContext) - Method in class org.apache.hadoop.hbase.ipc.NettyRpcServerChannelWritabilityHandler
 
channelWrite(GatheringByteChannel, BufferChain) - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcServer
Deprecated.
 
CHAOS_AGENT_REGISTRATION_EPIMERAL_ZNODE - Static variable in class org.apache.hadoop.hbase.chaos.ChaosConstants
 
CHAOS_AGENT_STATUS_PERSISTENT_ZNODE - Static variable in class org.apache.hadoop.hbase.chaos.ChaosConstants
 
CHAOS_TEST_ROOT_ZNODE - Static variable in class org.apache.hadoop.hbase.chaos.ChaosConstants
 
org.apache.hadoop.hbase.chaos.ChaosAgent - Class in org.apache.hadoop.hbase.chaos
An agent for executing destructive actions for ChaosMonkey.
ChaosAgent(Configuration, String, String) - Constructor for class org.apache.hadoop.hbase.chaos.ChaosAgent
 
CHAOSAGENT_SHELL_USER - Static variable in class org.apache.hadoop.hbase.chaos.ChaosConstants
 
org.apache.hadoop.hbase.chaos.ChaosAgent.LocalShell - Class in org.apache.hadoop.hbase.chaos
Executes Command locally.
org.apache.hadoop.hbase.chaos.ChaosConstants - Class in org.apache.hadoop.hbase.chaos
ChaosConstant holds a bunch of Choas-related Constants
ChaosConstants() - Constructor for class org.apache.hadoop.hbase.chaos.ChaosConstants
 
org.apache.hadoop.hbase.chaos.ChaosService - Class in org.apache.hadoop.hbase.chaos
Class used to start/stop Chaos related services (currently chaosagent)
ChaosService() - Constructor for class org.apache.hadoop.hbase.chaos.ChaosService
 
org.apache.hadoop.hbase.chaos.ChaosUtils - Class in org.apache.hadoop.hbase.chaos
ChaosUtils holds a bunch of useful functions like getting hostname and getting ZooKeeper quorum.
ChaosUtils() - Constructor for class org.apache.hadoop.hbase.chaos.ChaosUtils
 
character(Character) - Method in class org.apache.hadoop.hbase.hbtop.screen.top.InputModeScreenPresenter
 
Character - Enum constant in enum org.apache.hadoop.hbase.hbtop.terminal.KeyPress.Type
 
check(Mutation) - Method in class org.apache.hadoop.hbase.quotas.policies.DefaultViolationPolicyEnforcement
 
check(Mutation) - Method in class org.apache.hadoop.hbase.quotas.policies.DisableTableViolationPolicyEnforcement
 
check(Mutation) - Method in class org.apache.hadoop.hbase.quotas.policies.MissingSnapshotViolationPolicyEnforcement
 
check(Mutation) - Method in class org.apache.hadoop.hbase.quotas.policies.NoInsertsViolationPolicyEnforcement
 
check(Mutation) - Method in class org.apache.hadoop.hbase.quotas.policies.NoWritesViolationPolicyEnforcement
 
check(Mutation) - Method in interface org.apache.hadoop.hbase.quotas.SpaceViolationPolicyEnforcement
Checks the given Mutation against this policy.
CHECK - Enum constant in enum org.apache.hadoop.hbase.master.SplitLogManager.ResubmitDirective
Deprecated.
 
CHECK_AND_DELETE_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
CHECK_AND_MUTATE - Enum constant in enum org.apache.hadoop.hbase.quotas.OperationQuota.OperationType
 
CHECK_AND_MUTATE - Enum constant in enum org.apache.hadoop.hbase.regionserver.Region.Operation
 
CHECK_AND_MUTATE_BLOCK_BYTES_SCANNED_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
CHECK_AND_MUTATE_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
CHECK_AND_PUT_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
CHECK_MUTATE_FAILED_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
CHECK_MUTATE_FAILED_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
CHECK_MUTATE_PASSED_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
CHECK_MUTATE_PASSED_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
checkAndAddToActiveSize(MutableSegment, Cell, MemStoreSizing) - Method in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
Check whether anything need to be done based on the current active set size.
checkAndDelete(byte[], byte[], byte[], byte[], Delete) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated.
checkAndDelete(byte[], byte[], byte[], byte[], Delete) - Method in interface org.apache.hadoop.hbase.client.Table
Deprecated.
Since 2.0.0. Will be removed in 3.0.0. Use Table.checkAndMutate(byte[], byte[])
checkAndDelete(byte[], byte[], byte[], CompareOperator, byte[], Delete) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated.
checkAndDelete(byte[], byte[], byte[], CompareOperator, byte[], Delete) - Method in interface org.apache.hadoop.hbase.client.Table
Deprecated.
Since 2.0.0. Will be removed in 3.0.0. Use Table.checkAndMutate(byte[], byte[])
checkAndDelete(byte[], byte[], byte[], CompareFilter.CompareOp, byte[], Delete) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated.
checkAndDelete(byte[], byte[], byte[], CompareFilter.CompareOp, byte[], Delete) - Method in interface org.apache.hadoop.hbase.client.Table
Deprecated.
Since 2.0.0. Will be removed in 3.0.0. Use Table.checkAndMutate(byte[], byte[])
checkAndGetInstance(Class<?>) - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
Called when a new Coprocessor class needs to be loaded.
checkAndGetInstance(Class<?>) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
checkAndGetInstance(Class<?>) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
 
checkAndGetInstance(Class<?>) - Method in class org.apache.hadoop.hbase.regionserver.RegionServerCoprocessorHost
 
checkAndGetInstance(Class<?>) - Method in class org.apache.hadoop.hbase.regionserver.wal.WALCoprocessorHost
 
checkAndGetReversed(List<Filter>, boolean) - Static method in class org.apache.hadoop.hbase.filter.FilterListBase
 
checkAndLoadInstance(Class<?>, int, Configuration) - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
 
checkAndMarkRunningHbck(Configuration, RetryCounter) - Static method in class org.apache.hadoop.hbase.util.HBaseFsck
Deprecated.
This method maintains a lock using a file.
checkAndMutate(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
Deprecated.
Since 2.4.0, will be removed in 4.0.0. For internal test use only, do not use it any more.
checkAndMutate(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated.
checkAndMutate(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.client.Table
Deprecated.
Since 2.4.0, will be removed in 4.0.0. For internal test use only, do not use it any more.
checkAndMutate(byte[], byte[], byte[], CompareOperator, byte[], RowMutations) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated.
checkAndMutate(byte[], byte[], byte[], CompareOperator, byte[], RowMutations) - Method in interface org.apache.hadoop.hbase.client.Table
Deprecated.
Since 2.0.0. Will be removed in 3.0.0. Use Table.checkAndMutate(byte[], byte[])
checkAndMutate(byte[], byte[], byte[], CompareOperator, ByteArrayComparable, Mutation) - Method in interface org.apache.hadoop.hbase.regionserver.Region
Deprecated.
since 2.4.0 and will be removed in 4.0.0. Use Region.checkAndMutate(CheckAndMutate) instead.
checkAndMutate(byte[], byte[], byte[], CompareOperator, ByteArrayComparable, TimeRange, Mutation) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Deprecated.
checkAndMutate(byte[], byte[], byte[], CompareOperator, ByteArrayComparable, TimeRange, Mutation) - Method in interface org.apache.hadoop.hbase.regionserver.Region
Deprecated.
since 2.4.0 and will be removed in 4.0.0. Use Region.checkAndMutate(CheckAndMutate) instead.
checkAndMutate(byte[], byte[], byte[], CompareFilter.CompareOp, byte[], RowMutations) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated.
checkAndMutate(byte[], byte[], byte[], CompareFilter.CompareOp, byte[], RowMutations) - Method in interface org.apache.hadoop.hbase.client.Table
Deprecated.
Since 2.0.0. Will be removed in 3.0.0. Use Table.checkAndMutate(byte[], byte[])
checkAndMutate(byte[], Filter) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
Deprecated.
Since 2.4.0, will be removed in 4.0.0. For internal test use only, do not use it any more.
checkAndMutate(byte[], Filter) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated.
checkAndMutate(byte[], Filter) - Method in interface org.apache.hadoop.hbase.client.Table
Deprecated.
Since 2.4.0, will be removed in 4.0.0. For internal test use only, do not use it any more.
checkAndMutate(byte[], Filter, Mutation) - Method in interface org.apache.hadoop.hbase.regionserver.Region
Deprecated.
since 2.4.0 and will be removed in 4.0.0. Use Region.checkAndMutate(CheckAndMutate) instead.
checkAndMutate(byte[], Filter, TimeRange, Mutation) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Deprecated.
checkAndMutate(byte[], Filter, TimeRange, Mutation) - Method in interface org.apache.hadoop.hbase.regionserver.Region
Deprecated.
since 2.4.0 and will be removed in 4.0.0. Use Region.checkAndMutate(CheckAndMutate) instead.
checkAndMutate(List<CheckAndMutate>) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
Batch version of checkAndMutate.
checkAndMutate(List<CheckAndMutate>) - Method in class org.apache.hadoop.hbase.client.HTable
 
checkAndMutate(List<CheckAndMutate>) - Method in interface org.apache.hadoop.hbase.client.Table
Batch version of checkAndMutate.
checkAndMutate(CheckAndMutate) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
checkAndMutate that atomically checks if a row matches the specified condition.
checkAndMutate(CheckAndMutate) - Method in class org.apache.hadoop.hbase.client.HTable
 
checkAndMutate(CheckAndMutate) - Method in interface org.apache.hadoop.hbase.client.Table
checkAndMutate that atomically checks if a row matches the specified condition.
checkAndMutate(CheckAndMutate) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
checkAndMutate(CheckAndMutate) - Method in interface org.apache.hadoop.hbase.regionserver.Region
Atomically checks if a row matches the conditions and if it does, it performs the actions.
checkAndMutate(CheckAndMutate, long, long) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
CheckAndMutate - Class in org.apache.hadoop.hbase.client
Used to perform CheckAndMutate operations.
CheckAndMutate.Builder - Class in org.apache.hadoop.hbase.client
A builder class for building a CheckAndMutate object.
checkAndMutateAll(List<CheckAndMutate>) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
A simple version of batch checkAndMutate.
org.apache.hadoop.hbase.client.CheckAndMutateResult - Class in org.apache.hadoop.hbase.client
Represents a result of a CheckAndMutate operation
CheckAndMutateResult(boolean, Result) - Constructor for class org.apache.hadoop.hbase.client.CheckAndMutateResult
 
checkAndPut(byte[], byte[], byte[], byte[], Put) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated.
checkAndPut(byte[], byte[], byte[], byte[], Put) - Method in interface org.apache.hadoop.hbase.client.Table
Deprecated.
Since 2.0.0. Will be removed in 3.0.0. Use Table.checkAndMutate(byte[], byte[])
checkAndPut(byte[], byte[], byte[], CompareOperator, byte[], Put) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated.
checkAndPut(byte[], byte[], byte[], CompareOperator, byte[], Put) - Method in interface org.apache.hadoop.hbase.client.Table
Deprecated.
Since 2.0.0. Will be removed in 3.0.0. Use Table.checkAndMutate(byte[], byte[])
checkAndPut(byte[], byte[], byte[], CompareFilter.CompareOp, byte[], Put) - Method in class org.apache.hadoop.hbase.client.HTable
Deprecated.
checkAndPut(byte[], byte[], byte[], CompareFilter.CompareOp, byte[], Put) - Method in interface org.apache.hadoop.hbase.client.Table
Deprecated.
Since 2.0.0. Will be removed in 3.0.0. Use Table.checkAndMutate(byte[], byte[])
checkAndPut(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, Mutation, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
 
checkAndRowMutate(byte[], byte[], byte[], CompareOperator, ByteArrayComparable, RowMutations) - Method in interface org.apache.hadoop.hbase.regionserver.Region
Deprecated.
since 2.4.0 and will be removed in 4.0.0. Use Region.checkAndMutate(CheckAndMutate) instead.
checkAndRowMutate(byte[], byte[], byte[], CompareOperator, ByteArrayComparable, TimeRange, RowMutations) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Deprecated.
checkAndRowMutate(byte[], byte[], byte[], CompareOperator, ByteArrayComparable, TimeRange, RowMutations) - Method in interface org.apache.hadoop.hbase.regionserver.Region
Deprecated.
since 2.4.0 and will be removed in 4.0.0. Use Region.checkAndMutate(CheckAndMutate) instead.
checkAndRowMutate(byte[], Filter, RowMutations) - Method in interface org.apache.hadoop.hbase.regionserver.Region
Deprecated.
since 2.4.0 and will be removed in 4.0.0. Use Region.checkAndMutate(CheckAndMutate) instead.
checkAndRowMutate(byte[], Filter, TimeRange, RowMutations) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Deprecated.
checkAndRowMutate(byte[], Filter, TimeRange, RowMutations) - Method in interface org.apache.hadoop.hbase.regionserver.Region
Deprecated.
since 2.4.0 and will be removed in 4.0.0. Use Region.checkAndMutate(CheckAndMutate) instead.
checkAndSetZNodeAcls() - Method in class org.apache.hadoop.hbase.zookeeper.ZKWatcher
On master start, we check the znode ACLs under the root directory and set the ACLs properly if needed.
checkAndUpdateNamespaceRegionQuota(TableName, int) - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
 
checkBatchQuota(int, int) - Method in class org.apache.hadoop.hbase.quotas.DefaultOperationQuota
 
checkBatchQuota(int, int) - Method in class org.apache.hadoop.hbase.quotas.ExceedOperationQuota
 
checkBatchQuota(int, int) - Method in interface org.apache.hadoop.hbase.quotas.OperationQuota
Checks if it is possible to execute the specified operation.
checkBatchQuota(Region, List<ClientProtos.Action>, boolean) - Method in class org.apache.hadoop.hbase.quotas.RegionServerRpcQuotaManager
Check the quota for the current (rpc-context) user.
checkBatchQuota(Region, OperationQuota.OperationType) - Method in class org.apache.hadoop.hbase.quotas.RegionServerRpcQuotaManager
Check the quota for the current (rpc-context) user.
checkBlockBoundary() - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterImpl
At a block boundary, write all the inline blocks and opens new block.
checkClassLoading(Configuration, TableDescriptor) - Static method in class org.apache.hadoop.hbase.util.TableDescriptorChecker
 
checkClientTrusted(X509Certificate[], String) - Method in class org.apache.hadoop.hbase.io.crypto.tls.HBaseTrustManager
 
checkClientTrusted(X509Certificate[], String, Socket) - Method in class org.apache.hadoop.hbase.io.crypto.tls.HBaseTrustManager
 
checkClientTrusted(X509Certificate[], String, SSLEngine) - Method in class org.apache.hadoop.hbase.io.crypto.tls.HBaseTrustManager
 
checkClusterIdExists(FileSystem, Path, long) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Checks that a cluster ID file exists in the HBase root directory
checkColFamDir(Path) - Method in class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
Check all files in a column family dir.
checkColumn(Cell, byte) - Method in interface org.apache.hadoop.hbase.regionserver.querymatcher.ColumnTracker
Checks if the column is present in the list of requested columns by returning the match code instance.
checkColumn(Cell, byte) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ExplicitColumnTracker
Checks if the column is present in the list of requested columns by returning the match code instance.
checkColumn(Cell, byte) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.NewVersionBehaviorTracker
 
checkColumn(Cell, byte) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanWildcardColumnTracker
Checks if the column is present in the list of requested columns by returning the match code instance.
checkCompression(Configuration, TableDescriptor) - Static method in class org.apache.hadoop.hbase.util.TableDescriptorChecker
 
checkConfigurationChange(Configuration, Configuration, String...) - Static method in class org.apache.hadoop.hbase.util.CoprocessorConfigurationUtil
 
checkDeleted(DeleteTracker, Cell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher
 
checkDfsSafeMode(Configuration) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Check whether dfs is in safemode.
checkDifferencesWithOldPlan(Map<TableName, Integer>, Map<String, Map<String, Float>>, FavoredNodesPlan) - Method in class org.apache.hadoop.hbase.master.RegionPlacementMaintainer
Compares two plans and check whether the locality dropped or increased (prints the information as a string) also prints the baseline locality
checkEncryption(Configuration, TableDescriptor) - Static method in class org.apache.hadoop.hbase.util.TableDescriptorChecker
 
checkExists(ZKWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Check if the specified node exists.
checkFailed() - Method in class org.apache.hadoop.hbase.ipc.ServerRpcController
Throws an IOException back out if one is currently stored.
checkFamilies(Collection<byte[]>) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Check the collection of families for validity.
checkFileSystemAvailable(FileSystem) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Checks to see if the specified file system is available
checkFlushed() - Method in class org.apache.hadoop.hbase.codec.BaseEncoder
 
checkFlushed() - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
 
checkForAnd(byte[], int) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
Checks if the current index of filter string we are on is the beginning of the keyword 'AND'
checkForClusterFreeHeapMemoryLimit(Configuration) - Static method in class org.apache.hadoop.hbase.io.util.MemorySizeUtil
Checks whether we have enough heap memory left out after portion for Memstore and Block cache.
checkForCreateTable(Configuration, TableDescriptor) - Static method in class org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileTrackerValidationUtils
Pre check when creating a new table.
checkFormatVersion(int) - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
Checks the given HFile format version, and throws an exception if invalid.
checkForModifyTable(Configuration, TableDescriptor, TableDescriptor, boolean) - Static method in class org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileTrackerValidationUtils
Pre check when modifying a table.
checkForOr(byte[], int) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
Checks if the current index of filter string we are on is the beginning of the keyword 'OR'
checkForSkip(byte[], int) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
Checks if the current index of filter string we are on is the beginning of the keyword 'SKIP'
checkForTagsLength(int) - Static method in interface org.apache.hadoop.hbase.RawCell
Check the length of tags.
checkForWhile(byte[], int) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
Checks if the current index of filter string we are on is the beginning of the keyword 'WHILE'
checkHFile(Path) - Method in class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
Checks a path to see if it is a valid hfile.
checkHFileVersion(Configuration) - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
 
checkHttpSecurity(SaslUtil.QualityOfProtection, Configuration) - Method in class org.apache.hadoop.hbase.thrift.ThriftServer
 
checkIfBaseNodeAvailable() - Method in class org.apache.hadoop.hbase.zookeeper.ZKNodeTracker
Checks if the baseznode set as per the property 'zookeeper.znode.parent' exists.
checkIfRegionServerIsRemote() - Method in class org.apache.hadoop.hbase.client.ScannerCallable
compare the local machine hostname with region server's hostname to decide if hbase client connects to a remote region server
checkIfShouldMoveSystemRegionAsync() - Method in class org.apache.hadoop.hbase.master.HMaster
 
checkIfShouldMoveSystemRegionAsync() - Method in interface org.apache.hadoop.hbase.master.MasterServices
Called when a new RegionServer is added to the cluster.
checkImageManifestExist(HashMap<TableName, BackupManifest>, TableName[], Configuration, Path, String) - Static method in class org.apache.hadoop.hbase.backup.HBackupFileSystem
Check whether the backup image path and there is manifest file in the path.
checkKey(Cell) - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterImpl
Checks that the given Cell's key does not violate the key order.
checkKeyLen(int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
Returns True if v <= 0 or v > current block buffer limit.
checkKeyValueLen() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
Check key and value lengths are wholesome.
checkLen(int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
Returns True if v < 0 or v > current block buffer limit.
checkLogLowReplication(long) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
 
checkMobColFamDir(Path) - Method in class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
Check all files in a mob column family dir.
checkMobFile(Path) - Method in class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
Checks a path to see if it is a valid mob file.
checkNamespaceTableAndRegionQuota(TableName, int) - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
 
checkOnlyMemStore() - Method in class org.apache.hadoop.hbase.regionserver.InternalScan
StoreFiles will not be scanned.
checkOnlyStoreFiles() - Method in class org.apache.hadoop.hbase.regionserver.InternalScan
MemStore will not be scanned.
checkOOME(Throwable) - Method in interface org.apache.hadoop.hbase.ipc.HBaseRPCErrorHandler
Take actions on the event of an OutOfMemoryError.
checkOOME(Throwable) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
 
checkOpen() - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
Called to verify that this server is up and running.
checkOutputSpecs(FileSystem, JobConf) - Method in class org.apache.hadoop.hbase.mapred.TableOutputFormat
 
checkOutputSpecs(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableOutputFormat
 
checkOutputSpecs(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputFormat
Checks if the output table exists and is enabled.
checkPermission(String) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
checkProcessTimeAndSpeed(DatanodeInfo, long, long, long, int) - Method in class org.apache.hadoop.hbase.io.asyncfs.monitor.StreamSlowMonitor
Check if the packet process time shows that the relevant datanode is a slow node.
checkQuota(long, long, long, long, long, long) - Method in interface org.apache.hadoop.hbase.quotas.QuotaLimiter
Checks if it is possible to execute the specified operation.
checkQuota(long, long, long, long, long, long) - Method in class org.apache.hadoop.hbase.quotas.TimeBasedLimiter
 
checkQuotaToCreateTable(TableName, int) - Method in class org.apache.hadoop.hbase.namespace.NamespaceAuditor
Check quota to create table.
checkQuotaToSplitRegion(RegionInfo) - Method in class org.apache.hadoop.hbase.namespace.NamespaceAuditor
 
checkQuotaToUpdateRegion(TableName, int) - Method in class org.apache.hadoop.hbase.namespace.NamespaceAuditor
Check and update region count quota for an existing table.
checkRefCount() - Method in class org.apache.hadoop.hbase.nio.ByteBuff
Checks that there are still references to the buffer.
checkRegionBoundaries() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
Deprecated.
 
checkRegionChain(TableIntegrityErrorHandler) - Method in class org.apache.hadoop.hbase.util.HbckTableInfo
Check the region chain (from META) of this table.
checkRegionDir(Path) - Method in class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
Check all column families in a region dir.
checkRow(Cell) - Method in class org.apache.hadoop.hbase.io.encoding.RowIndexEncoderV1
 
checkScanOrder(Cell, Cell, CellComparator) - Method in class org.apache.hadoop.hbase.regionserver.ReversedStoreScanner
 
checkScanOrder(Cell, Cell, CellComparator) - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
Check whether scan as expected order
checkScanQuota(Region, ClientProtos.ScanRequest, long, long, long) - Method in class org.apache.hadoop.hbase.quotas.RegionServerRpcQuotaManager
Check the quota for the current (rpc-context) user.
checkScanQuota(ClientProtos.ScanRequest, long, long, long) - Method in class org.apache.hadoop.hbase.quotas.DefaultOperationQuota
 
checkScanQuota(ClientProtos.ScanRequest, long, long, long) - Method in class org.apache.hadoop.hbase.quotas.ExceedOperationQuota
 
checkScanQuota(ClientProtos.ScanRequest, long, long, long) - Method in interface org.apache.hadoop.hbase.quotas.OperationQuota
Checks if it is possible to execute the scan.
checkServerTrusted(X509Certificate[], String) - Method in class org.apache.hadoop.hbase.io.crypto.tls.HBaseTrustManager
 
checkServerTrusted(X509Certificate[], String, Socket) - Method in class org.apache.hadoop.hbase.io.crypto.tls.HBaseTrustManager
 
checkServerTrusted(X509Certificate[], String, SSLEngine) - Method in class org.apache.hadoop.hbase.io.crypto.tls.HBaseTrustManager
 
checkServiceStarted() - Method in class org.apache.hadoop.hbase.master.HMaster
 
checkShortCircuitReadBufferSize(Configuration) - Static method in class org.apache.hadoop.hbase.util.CommonFSUtils
Check if short circuit read buffer size is set and if not, set it to hbase value.
checkShortCircuitReadBufferSize(Configuration) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Check if short circuit read buffer size is set and if not, set it to hbase value.
checkSizeAndGrow(int) - Method in class org.apache.hadoop.hbase.io.ByteBufferListOutputStream
 
checkSizeAndGrow(int) - Method in class org.apache.hadoop.hbase.io.ByteBufferOutputStream
 
checkSplit() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
checkSplit(boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Return the split point.
checkState(int) - Method in interface org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture.WaitForStateCallable
 
CHECKSUM_BUF_SIZE - Static variable in class org.apache.hadoop.hbase.io.hfile.ChecksumUtil
 
CHECKSUM_FAILURES_DESC - Static variable in interface org.apache.hadoop.hbase.io.MetricsIOSource
 
CHECKSUM_FAILURES_KEY - Static variable in interface org.apache.hadoop.hbase.io.MetricsIOSource
 
CHECKSUM_TYPE_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
The name of the configuration parameter that specifies the name of an algorithm that is used to compute checksums for newly created blocks.
checksumOk() - Method in class org.apache.hadoop.hbase.io.FSDataInputStreamWrapper
Report that checksum was ok, so we may ponder going back to HBase checksum.
org.apache.hadoop.hbase.util.ChecksumType - Enum in org.apache.hadoop.hbase.util
Checksum types.
org.apache.hadoop.hbase.io.hfile.ChecksumUtil - Class in org.apache.hadoop.hbase.io.hfile
Utility methods to compute and validate checksums.
ChecksumUtil() - Constructor for class org.apache.hadoop.hbase.io.hfile.ChecksumUtil
 
checkTableModifiable(TableName) - Method in class org.apache.hadoop.hbase.master.HMaster
 
checkTableModifiable(TableName) - Method in interface org.apache.hadoop.hbase.master.MasterServices
Check table is modifiable; i.e.
checkTables(Collection<Path>) - Method in class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
Check the specified table dirs for bad hfiles.
checkTasks() - Method in interface org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination
Deprecated.
tells Coordination that it should check for new tasks
checkTasks() - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
 
checkTaskStillAvailable(String) - Method in interface org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination
Deprecated.
Check that the task is still there
checkTaskStillAvailable(String) - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
 
checkTimestamps(Map<byte[], List<Cell>>, long) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Check the collection of families for valid timestamps
checkUnDeletedQueues() - Method in class org.apache.hadoop.hbase.util.hbck.ReplicationChecker
 
checkValue(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterImpl
Checks the given value for validity.
checkVersion(FileSystem, Path, boolean) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Verifies current version of file system
checkVersion(FileSystem, Path, boolean, int, int) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Verifies current version of file system
checkVersions(Cell, long, byte, boolean) - Method in interface org.apache.hadoop.hbase.regionserver.querymatcher.ColumnTracker
Keeps track of the number of versions for the columns asked for.
checkVersions(Cell, long, byte, boolean) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ExplicitColumnTracker
 
checkVersions(Cell, long, byte, boolean) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.NewVersionBehaviorTracker
 
checkVersions(Cell, long, byte, boolean) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanWildcardColumnTracker
Keeps track of the number of versions for the columns asked for.
chore() - Method in class org.apache.hadoop.hbase.HealthCheckChore
 
chore() - Method in class org.apache.hadoop.hbase.master.ClusterStatusPublisher
 
chore() - Method in class org.apache.hadoop.hbase.master.OldWALsDirSizeChore
 
chore() - Method in class org.apache.hadoop.hbase.master.RegionsRecoveryChore
 
chore() - Method in class org.apache.hadoop.hbase.mob.MobFileCleanerChore
 
chore() - Method in class org.apache.hadoop.hbase.mob.MobFileCompactionChore
 
chore() - Method in class org.apache.hadoop.hbase.mob.RSMobFileCleanerChore
 
chore() - Method in class org.apache.hadoop.hbase.namequeues.NamedQueueServiceChore
 
chore() - Method in class org.apache.hadoop.hbase.quotas.FileSystemUtilizationChore
 
chore() - Method in class org.apache.hadoop.hbase.quotas.QuotaObserverChore
 
chore() - Method in class org.apache.hadoop.hbase.quotas.RegionSizeReportingChore
 
chore() - Method in class org.apache.hadoop.hbase.quotas.SnapshotQuotaObserverChore
 
chore() - Method in class org.apache.hadoop.hbase.quotas.SpaceQuotaRefresherChore
 
chore() - Method in class org.apache.hadoop.hbase.regionserver.BrokenStoreFileCleaner
 
chore() - Method in class org.apache.hadoop.hbase.regionserver.CompactedHFilesDischarger
 
chore() - Method in class org.apache.hadoop.hbase.regionserver.StorefileRefresherChore
 
chore() - Method in class org.apache.hadoop.hbase.ScheduledChore
The task to execute on each scheduled execution of the Chore
CHORE_SERVICE_INITIAL_POOL_SIZE - Static variable in class org.apache.hadoop.hbase.ChoreService
The initial number of threads in the core pool for the ChoreService.
CHORE_SERVICE_PREFIX - Static variable in class org.apache.hadoop.hbase.chaos.ChaosConstants
 
choreForTesting() - Method in class org.apache.hadoop.hbase.ScheduledChore
 
org.apache.hadoop.hbase.ChoreService - Class in org.apache.hadoop.hbase
ChoreService is a service that can be used to schedule instances of ScheduledChore to run periodically while sharing threads.
ChoreService(String) - Constructor for class org.apache.hadoop.hbase.ChoreService
 
ChoreService(String, boolean) - Constructor for class org.apache.hadoop.hbase.ChoreService
 
ChoreService(String, int, boolean) - Constructor for class org.apache.hadoop.hbase.ChoreService
 
org.apache.hadoop.hbase.regionserver.Chunk - Class in org.apache.hadoop.hbase.regionserver
A chunk of memory out of which allocations are sliced.
Chunk(int, int, ChunkCreator.ChunkType) - Constructor for class org.apache.hadoop.hbase.regionserver.Chunk
Create an uninitialized chunk.
Chunk(int, int, ChunkCreator.ChunkType, boolean) - Constructor for class org.apache.hadoop.hbase.regionserver.Chunk
Create an uninitialized chunk.
CHUNK_MAP - Enum constant in enum org.apache.hadoop.hbase.regionserver.CompactingMemStore.IndexType
 
CHUNK_POOL_INITIALSIZE_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MemStoreLAB
 
CHUNK_POOL_MAXSIZE_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MemStoreLAB
 
CHUNK_SIZE_DEFAULT - Static variable in interface org.apache.hadoop.hbase.regionserver.MemStoreLAB
 
CHUNK_SIZE_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MemStoreLAB
 
org.apache.hadoop.hbase.regionserver.ChunkCreator - Class in org.apache.hadoop.hbase.regionserver
Does the management of memstoreLAB chunk creations.
org.apache.hadoop.hbase.regionserver.ChunkCreator.ChunkType - Enum in org.apache.hadoop.hbase.regionserver
Types of chunks, based on their sizes
org.apache.hadoop.hbase.io.crypto.Cipher - Class in org.apache.hadoop.hbase.io.crypto
A common interface for a cryptographic algorithm.
Cipher(CipherProvider) - Constructor for class org.apache.hadoop.hbase.io.crypto.Cipher
 
CIPHER_AES - Static variable in class org.apache.hadoop.hbase.HConstants
Default cipher for encryption
CIPHER_CLASSES_KEY - Static variable in class org.apache.hadoop.hbase.io.crypto.aes.CommonsCryptoAES
 
CIPHER_JCE_PROVIDER_KEY - Static variable in class org.apache.hadoop.hbase.io.crypto.aes.CommonsCryptoAES
 
CIPHER_MODE_KEY - Static variable in class org.apache.hadoop.hbase.io.crypto.aes.AES
 
CIPHER_MODE_KEY - Static variable in class org.apache.hadoop.hbase.io.crypto.aes.CommonsCryptoAES
 
CIPHER_PROVIDER_KEY - Static variable in class org.apache.hadoop.hbase.io.crypto.aes.AES
 
org.apache.hadoop.hbase.io.crypto.CipherProvider - Interface in org.apache.hadoop.hbase.io.crypto
An CipherProvider contributes support for various cryptographic Ciphers.
claimQueue(ServerName, String, ServerName) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueueStorage
Change ownership for the queue identified by queueId and belongs to a dead region server.
org.apache.hadoop.hbase.util.Classes - Class in org.apache.hadoop.hbase.util
Utilities for class manipulation.
Classes() - Constructor for class org.apache.hadoop.hbase.util.Classes
 
classifyExs(List<Throwable>) - Static method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
 
org.apache.hadoop.hbase.util.ClassLoaderBase - Class in org.apache.hadoop.hbase.util
Base class loader that defines couple shared constants used by sub-classes.
ClassLoaderBase(ClassLoader) - Constructor for class org.apache.hadoop.hbase.util.ClassLoaderBase
Creates a DynamicClassLoader that can load classes dynamically from jar files under a specific folder.
CLASSNAME_KEY - Static variable in interface org.apache.hadoop.hbase.client.BufferedMutator
Key to use setting non-default BufferedMutator implementation in Configuration.
org.apache.hadoop.hbase.util.ClassSize - Class in org.apache.hadoop.hbase.util
Class for determining the "size" of a class, an attempt to calculate the actual bytes that an object of this class will occupy in memory The core of this class is taken from the Derby project
ClassSize() - Constructor for class org.apache.hadoop.hbase.util.ClassSize
 
clean() - Method in class org.apache.hadoop.hbase.io.ByteBuffAllocator
Free all direct buffers if allocated, mainly used for testing.
cleanerChoreSwitch(boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
Enable/Disable the cleaner chore.
cleanerChoreSwitch(boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Turn the cleaner chore on/off.
cleanerChoreSwitch(boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
cleanExpiredMobFiles(String, ColumnFamilyDescriptor) - Method in class org.apache.hadoop.hbase.mob.ExpiredMobFileCleaner
Cleans the MOB files when they're expired and their min versions are 0.
cleanExpiredMobFiles(FileSystem, Configuration, TableName, ColumnFamilyDescriptor, CacheConfig, long) - Static method in class org.apache.hadoop.hbase.mob.MobUtils
Cleans the expired mob files.
cleanReplicationBarrier() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
Deprecated.
 
cleanRestoreDir(Job, String) - Static method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormat
clean restore directory after snapshot scan job
cleanRestoreDir(Job, String) - Static method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl
clean restore directory after snapshot scan job
cleanup() - Method in interface org.apache.hadoop.hbase.ipc.RpcCall
Do the necessary cleanup after the call if needed.
cleanup() - Method in class org.apache.hadoop.hbase.ipc.ServerCall
 
cleanup() - Method in class org.apache.hadoop.hbase.master.ClusterStatusPublisher
 
cleanup() - Method in class org.apache.hadoop.hbase.ScheduledChore
Override to run cleanup tasks when the Chore encounters an error and must stop running
cleanup(Mapper.Context) - Method in class org.apache.hadoop.hbase.mapreduce.SyncTable.SyncMapper
 
cleanup(Mapper.Context) - Method in class org.apache.hadoop.hbase.mapreduce.HashTable.HashMapper
 
cleanup(Mapper.Context) - Method in class org.apache.hadoop.hbase.mapreduce.WALPlayer.WALMapper
 
CLEANUP_INTERVAL - Static variable in class org.apache.hadoop.hbase.rest.RESTServlet
 
CLEANUP_INTERVAL - Static variable in class org.apache.hadoop.hbase.thrift.HBaseServiceHandler
 
cleanupBulkLoad(Connection, String) - Method in class org.apache.hadoop.hbase.client.SecureBulkLoadClient
 
cleanupBulkLoad(HRegion, ClientProtos.CleanupBulkLoadRequest) - Method in class org.apache.hadoop.hbase.regionserver.SecureBulkLoadManager
 
cleanupBulkLoad(RpcController, ClientProtos.CleanupBulkLoadRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
 
cleanupJob(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputCommitter
 
cleanupMergedRegion(RegionInfo) - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
Remove merged region
cleanupObsoleteMobFiles(Configuration, TableName, Admin) - Static method in class org.apache.hadoop.hbase.mob.MobFileCleanupUtil
Performs housekeeping file cleaning (called by MOB Cleaner chore)
clear() - Method in interface org.apache.hadoop.hbase.CellBuilder
Remove all internal elements from builder.
clear() - Method in class org.apache.hadoop.hbase.client.BatchScanResultCache
 
clear() - Method in class org.apache.hadoop.hbase.CompoundConfiguration
These methods are unsupported, and no code using CompoundConfiguration depend upon them.
clear() - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
 
clear() - Method in interface org.apache.hadoop.hbase.ExtendedCellBuilder
 
clear() - Method in class org.apache.hadoop.hbase.ExtendedCellBuilderImpl
 
clear() - Method in class org.apache.hadoop.hbase.hbtop.Record
 
clear() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.batch.BatchTerminal
 
clear() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.ScreenBuffer
 
clear() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.TerminalImpl
 
clear() - Method in interface org.apache.hadoop.hbase.hbtop.terminal.Terminal
 
clear() - Method in interface org.apache.hadoop.hbase.io.hfile.BlockIndexChunk
 
clear() - Method in class org.apache.hadoop.hbase.io.hfile.HFileInfo
 
clear() - Method in class org.apache.hadoop.hbase.io.TagCompressionContext
 
clear() - Method in interface org.apache.hadoop.hbase.io.util.Dictionary
Flushes the dictionary, empties all values.
clear() - Method in class org.apache.hadoop.hbase.io.util.LRUDictionary
 
clear() - Method in class org.apache.hadoop.hbase.ipc.AdaptiveLifoCoDelCallQueue
 
clear() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
 
clear() - Method in class org.apache.hadoop.hbase.metrics.MetricRegistries
Removes all the MetricRegisties.
clear() - Method in class org.apache.hadoop.hbase.quotas.NoOpRegionSizeStore
 
clear() - Method in interface org.apache.hadoop.hbase.quotas.RegionSizeStore
Removes all entries from the store.
clear() - Method in class org.apache.hadoop.hbase.quotas.RegionSizeStoreImpl
 
clear() - Method in interface org.apache.hadoop.hbase.RawCellBuilder
 
clear() - Method in class org.apache.hadoop.hbase.regionserver.CellFlatMap
 
clear() - Method in class org.apache.hadoop.hbase.regionserver.CellSet
 
clear() - Method in class org.apache.hadoop.hbase.regionserver.wal.SyncFutureCache
 
clear() - Method in class org.apache.hadoop.hbase.thrift.CallQueue
 
clear() - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
 
clear() - Method in interface org.apache.hadoop.hbase.util.HbckErrorReporter
Deprecated.
 
clear() - Method in class org.apache.hadoop.hbase.util.PoolMap
 
clear() - Method in interface org.apache.hadoop.hbase.util.PoolMap.Pool
 
clear() - Method in class org.apache.hadoop.hbase.util.SortedList
 
clear(Configuration) - Static method in class org.apache.hadoop.hbase.ZNodeClearer
Delete the master znode if its content (ServerName string) is the same as the one in the znode file.
clearAll() - Static method in class org.apache.hadoop.hbase.hbtop.terminal.impl.EscapeSequences
 
clearBlockCache(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
Clear all the blocks corresponding to this table from BlockCache.
clearBlockCache(TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Clear all the blocks corresponding to this table from BlockCache.
clearBlockCache(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Clear all the blocks corresponding to this table from BlockCache.
clearCache() - Method in class org.apache.hadoop.hbase.client.MetaCache
Delete all cached entries.
clearCache() - Method in class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache
Clears the cache.
clearCache() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
Clears the cache.
clearCache() - Static method in class org.apache.hadoop.hbase.util.CoprocessorClassLoader
 
clearCache(RegionInfo) - Method in class org.apache.hadoop.hbase.client.MetaCache
Deletes the cached location of the region if necessary, based on some error from source.
Synchronized because of calls in cacheLocation which need to be executed atomically
clearCache(ServerName) - Method in class org.apache.hadoop.hbase.client.MetaCache
Delete all cached entries of a server.
clearCache(TableName) - Method in class org.apache.hadoop.hbase.client.MetaCache
Delete all cached entries of a table.
Synchronized because of calls in cacheLocation which need to be executed atomically
clearCache(TableName, byte[]) - Method in class org.apache.hadoop.hbase.client.MetaCache
Delete a cached location, no matter what it is.
clearCache(TableName, byte[], int) - Method in class org.apache.hadoop.hbase.client.MetaCache
Delete a cached location with specific replicaId.
Synchronized because of calls in cacheLocation which need to be executed atomically
clearCache(TableName, byte[], ServerName) - Method in class org.apache.hadoop.hbase.client.MetaCache
Delete a cached location for a table, row and server.
clearCaches(ServerName) - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
Clear any caches that pertain to server name sn.
clearCaches(ServerName) - Method in class org.apache.hadoop.hbase.client.ConnectionImplementation
 
clearCompactedFiles() - Method in interface org.apache.hadoop.hbase.regionserver.StoreFileManager
Clears all the compacted files and returns them.
clearCompactedFiles() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
 
clearCompactionQueues(ServerName, Set<String>) - Method in interface org.apache.hadoop.hbase.client.Admin
Clear compacting queues on a regionserver.
clearCompactionQueues(ServerName, Set<String>) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Clear compacting queues on a region server.
clearCompactionQueues(ServerName, Set<String>) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
clearCompactionQueues(RpcController, AdminProtos.ClearCompactionQueuesRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
 
clearCurrentRow() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher
Make ScanQueryMatcher.currentRow() return null.
clearDeadServers(List<ServerName>) - Method in interface org.apache.hadoop.hbase.client.Admin
Clear dead region servers from master.
clearDeadServers(List<ServerName>) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Clear dead region servers from master.
clearDeadServers(List<ServerName>) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
clearDeadServers(RpcController, MasterProtos.ClearDeadServersRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
clearDeadServers(RpcController, MasterProtos.ClearDeadServersRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
 
clearFiles() - Method in interface org.apache.hadoop.hbase.regionserver.StoreFileManager
Clears all the files currently in use and returns them.
clearFiles() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
 
clearFilters() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenModel
 
clearFilters() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenPresenter
 
clearHashCache() - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
 
clearLongCompactionsQueue() - Method in class org.apache.hadoop.hbase.regionserver.CompactSplit
 
clearNamedQueue() - Method in class org.apache.hadoop.hbase.namequeues.impl.BalancerDecisionQueueService
 
clearNamedQueue() - Method in class org.apache.hadoop.hbase.namequeues.impl.BalancerRejectionQueueService
 
clearNamedQueue() - Method in class org.apache.hadoop.hbase.namequeues.impl.SlowLogQueueService
 
clearNamedQueue() - Method in interface org.apache.hadoop.hbase.namequeues.NamedQueueService
Cleans up queues maintained by services.
clearNamedQueue() - Method in class org.apache.hadoop.hbase.namequeues.WALEventTrackerQueueService
 
clearNamedQueue(NamedQueuePayload.NamedQueueEvent) - Method in class org.apache.hadoop.hbase.namequeues.NamedQueueRecorder
clears queue records from ringbuffer
clearRegionBlockCache(RpcController, AdminProtos.ClearRegionBlockCacheRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
 
clearRegionCache() - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
Deprecated.
Connection.clearRegionLocationCache() instead.
clearRegionCache() - Method in class org.apache.hadoop.hbase.client.HTable
Explicitly clears the region cache to fetch the latest value from META.
clearRegionCache(TableName) - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
Allows flushing the region cache of all locations that pertain to tableName
clearRegionCache(TableName) - Method in class org.apache.hadoop.hbase.client.ConnectionImplementation
 
clearRegionCache(TableName, byte[]) - Method in class org.apache.hadoop.hbase.client.ConnectionImplementation
 
clearRegionLocationCache() - Method in interface org.apache.hadoop.hbase.client.AsyncConnection
Clear all the entries in the region location cache, for all the tables.
clearRegionLocationCache() - Method in class org.apache.hadoop.hbase.client.AsyncConnectionImpl
 
clearRegionLocationCache() - Method in interface org.apache.hadoop.hbase.client.AsyncTableRegionLocator
Clear all the entries in the region location cache.
clearRegionLocationCache() - Method in interface org.apache.hadoop.hbase.client.Connection
Clear all the entries in the region location cache, for all the tables.
clearRegionLocationCache() - Method in class org.apache.hadoop.hbase.client.ConnectionImplementation
 
clearRegionLocationCache() - Method in class org.apache.hadoop.hbase.client.HRegionLocator
 
clearRegionLocationCache() - Method in interface org.apache.hadoop.hbase.client.RegionLocator
Clear all the entries in the region location cache.
clearRegionLocationCache() - Method in class org.apache.hadoop.hbase.SharedConnection
 
clearRemainingLine() - Static method in class org.apache.hadoop.hbase.hbtop.terminal.impl.EscapeSequences
 
clearReplicationScope() - Method in class org.apache.hadoop.hbase.wal.WALKeyImpl
 
clearShortCompactionsQueue() - Method in class org.apache.hadoop.hbase.regionserver.CompactSplit
 
clearSlowLogResponses(Set<ServerName>) - Method in interface org.apache.hadoop.hbase.client.Admin
Clears online slow/large RPC logs from the provided list of RegionServers
clearSlowLogResponses(Set<ServerName>) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Clears online slow RPC logs from the provided list of RegionServers
clearSlowLogResponses(Set<ServerName>) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
clearSlowLogsResponses(RpcController, AdminProtos.ClearSlowLogResponseRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
 
clearSnapshot(long) - Method in class org.apache.hadoop.hbase.regionserver.AbstractMemStore
This method is protected under HStore#lock write lock,
and this method is used by HStore#updateStorefiles after flushing is completed.
The passed snapshot was successfully persisted; it can be let go.
clearSnapshot(long) - Method in interface org.apache.hadoop.hbase.regionserver.MemStore
Clears the current snapshot of the Memstore.
clearTerminal() - Method in class org.apache.hadoop.hbase.hbtop.screen.AbstractScreenView
 
org.apache.hadoop.hbase.http.ClickjackingPreventionFilter - Class in org.apache.hadoop.hbase.http
 
ClickjackingPreventionFilter() - Constructor for class org.apache.hadoop.hbase.http.ClickjackingPreventionFilter
 
org.apache.hadoop.hbase.rest.client.Client - Class in org.apache.hadoop.hbase.rest.client
A wrapper around HttpClient which provides some useful function and semantics for interacting with the REST gateway.
Client() - Constructor for class org.apache.hadoop.hbase.rest.client.Client
Default Constructor
Client(Cluster) - Constructor for class org.apache.hadoop.hbase.rest.client.Client
Constructor
Client(Cluster, boolean) - Constructor for class org.apache.hadoop.hbase.rest.client.Client
Constructor
Client(Cluster, String, Optional<String>, Optional<String>) - Constructor for class org.apache.hadoop.hbase.rest.client.Client
Constructor, allowing to define custom trust store (only for SSL connections)
Client(Cluster, Configuration, boolean) - Constructor for class org.apache.hadoop.hbase.rest.client.Client
Constructor
Client(Cluster, Configuration, String, Optional<String>, Optional<String>) - Constructor for class org.apache.hadoop.hbase.rest.client.Client
Constructor, allowing to define custom trust store (only for SSL connections)
CLIENT - Enum constant in enum org.apache.hadoop.hbase.hbtop.field.Field
 
CLIENT - Enum constant in enum org.apache.hadoop.hbase.hbtop.mode.Mode
 
CLIENT_BOOTSTRAP_NODE_LIMIT - Static variable in class org.apache.hadoop.hbase.regionserver.RSRpcServices
 
CLIENT_CONNECTION_REGISTRY_IMPL_CONF_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
Registry implementation to be used on the client side.
CLIENT_COUNT - Enum constant in enum org.apache.hadoop.hbase.hbtop.field.Field
 
CLIENT_NONCES_ENABLED_KEY - Static variable in interface org.apache.hadoop.hbase.client.NonceGenerator
 
CLIENT_PORT_STR - Static variable in class org.apache.hadoop.hbase.HConstants
The ZK client port key in the ZK properties map.
CLIENT_SIDE_METRICS_ENABLED_KEY - Static variable in class org.apache.hadoop.hbase.client.MetricsConnection
Set this key to true to enable metrics collection of client requests.
CLIENT_SIDE_TABLE_METRICS_ENABLED_KEY - Static variable in class org.apache.hadoop.hbase.client.MetricsConnection
Set this key to true to enable table metrics collection of client requests.
CLIENT_ZOOKEEPER_CLIENT_PORT - Static variable in class org.apache.hadoop.hbase.HConstants
Client port of ZooKeeper for client to locate meta
CLIENT_ZOOKEEPER_OBSERVER_MODE - Static variable in class org.apache.hadoop.hbase.HConstants
Indicate whether the client ZK are observer nodes of the server ZK
CLIENT_ZOOKEEPER_QUORUM - Static variable in class org.apache.hadoop.hbase.HConstants
Name of ZooKeeper quorum configuration parameter for client to locate meta.
org.apache.hadoop.hbase.rest.client.Client.ClientTrustStoreInitializationException - Exception in org.apache.hadoop.hbase.rest.client
 
org.apache.hadoop.hbase.client.ClientAsyncPrefetchScanner - Class in org.apache.hadoop.hbase.client
ClientAsyncPrefetchScanner implements async scanner behaviour.
ClientAsyncPrefetchScanner(Configuration, Scan, Scan, TableName, ClusterConnection, RpcRetryingCallerFactory, RpcControllerFactory, ExecutorService, int, int, int, ConnectionConfiguration, Map<String, byte[]>) - Constructor for class org.apache.hadoop.hbase.client.ClientAsyncPrefetchScanner
 
org.apache.hadoop.hbase.client.backoff.ClientBackoffPolicy - Interface in org.apache.hadoop.hbase.client.backoff
Configurable policy for the amount of time a client should wait for a new request to the server when given the server load statistics.
org.apache.hadoop.hbase.client.backoff.ClientBackoffPolicyFactory - Class in org.apache.hadoop.hbase.client.backoff
 
org.apache.hadoop.hbase.client.backoff.ClientBackoffPolicyFactory.NoBackoffPolicy - Class in org.apache.hadoop.hbase.client.backoff
Default backoff policy that doesn't create any backoff for the client, regardless of load
clientCertificateChain - Variable in class org.apache.hadoop.hbase.ipc.ServerCall
 
clientChannelClass() - Method in class org.apache.hadoop.hbase.util.NettyEventLoopGroupConfig
 
org.apache.hadoop.hbase.client.ClientCoprocessorRpcController - Class in org.apache.hadoop.hbase.client
Client side rpc controller for coprocessor implementation.
ClientCoprocessorRpcController() - Constructor for class org.apache.hadoop.hbase.client.ClientCoprocessorRpcController
 
org.apache.hadoop.hbase.exceptions.ClientExceptionsUtil - Class in org.apache.hadoop.hbase.exceptions
 
ClientMetricsImpl(String, long, long, long) - Constructor for class org.apache.hadoop.hbase.UserMetricsBuilder.ClientMetricsImpl
 
org.apache.hadoop.hbase.hbtop.mode.ClientModeStrategy - Class in org.apache.hadoop.hbase.hbtop.mode
Implementation for ModeStrategy for client Mode.
org.apache.hadoop.hbase.client.ClientScanner - Class in org.apache.hadoop.hbase.client
Implements the scanner interface for the HBase client.
ClientScanner(Configuration, Scan, Scan, TableName, ClusterConnection, RpcRetryingCallerFactory, RpcControllerFactory, ExecutorService, int, int, int, ConnectionConfiguration, Map<String, byte[]>) - Constructor for class org.apache.hadoop.hbase.client.ClientScanner
Create a new ClientScanner for the specified table Note that the passed Scan's start row maybe changed changed.
org.apache.hadoop.hbase.client.ClientServiceCallable<T> - Class in org.apache.hadoop.hbase.client
A RegionServerCallable set to use the Client protocol.
ClientServiceCallable(Connection, TableName, byte[], RpcController, int, Map<String, byte[]>) - Constructor for class org.apache.hadoop.hbase.client.ClientServiceCallable
 
org.apache.hadoop.hbase.client.ClientSideRegionScanner - Class in org.apache.hadoop.hbase.client
A client scanner for a region opened for read-only on the client side.
ClientSideRegionScanner(Configuration, FileSystem, Path, TableDescriptor, RegionInfo, Scan, ScanMetrics) - Constructor for class org.apache.hadoop.hbase.client.ClientSideRegionScanner
 
org.apache.hadoop.hbase.client.ClientSimpleScanner - Class in org.apache.hadoop.hbase.client
ClientSimpleScanner implements a sync scanner behaviour.
ClientSimpleScanner(Configuration, Scan, Scan, TableName, ClusterConnection, RpcRetryingCallerFactory, RpcControllerFactory, ExecutorService, int, int, int, ConnectionConfiguration, Map<String, byte[]>) - Constructor for class org.apache.hadoop.hbase.client.ClientSimpleScanner
 
org.apache.hadoop.hbase.snapshot.ClientSnapshotDescriptionUtils - Class in org.apache.hadoop.hbase.snapshot
Class to help with dealing with a snapshot description on the client side.
ClientTrustStoreInitializationException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.rest.client.Client.ClientTrustStoreInitializationException
 
org.apache.hadoop.hbase.client.ClientUtil - Class in org.apache.hadoop.hbase.client
 
ClientUtil() - Constructor for class org.apache.hadoop.hbase.client.ClientUtil
 
org.apache.hadoop.hbase.util.ClientUtils - Class in org.apache.hadoop.hbase.util
Common Utility class for clients
org.apache.hadoop.hbase.ClockOutOfSyncException - Exception in org.apache.hadoop.hbase
This exception is thrown by the master when a region server clock skew is too high.
ClockOutOfSyncException(String) - Constructor for exception org.apache.hadoop.hbase.ClockOutOfSyncException
 
clone() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
 
clone() - Method in class org.apache.hadoop.hbase.IndividualBytesFieldCell
Implement Cloneable interface
clone() - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
 
clone() - Method in class org.apache.hadoop.hbase.KeyValue
Clones a KeyValue.
clone() - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
Deprecated.
 
clone() - Method in class org.apache.hadoop.hbase.KeyValue.MetaComparator
Deprecated.
 
cloneFamily(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
 
cloneIfNecessary(ArrayList<Cell>) - Static method in class org.apache.hadoop.hbase.CellUtil
 
cloneIfNecessary(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
 
cloneQualifier(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
 
cloneRegionInfo(RegionInfo) - Method in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper
Create a new RegionInfo from the snapshot region info.
cloneRegionInfo(TableName, RegionInfo) - Static method in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper
 
cloneRow(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
get individual arrays for tests
cloneSnapshot(byte[], TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
since 2.3.0, will be removed in 3.0.0. Use Admin.cloneSnapshot(String, TableName) instead.
cloneSnapshot(String, TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
Create a new table by cloning the snapshot content.
cloneSnapshot(String, TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Create a new table by cloning the snapshot content.
cloneSnapshot(String, TableName, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
Create a new table by cloning the snapshot content.
cloneSnapshot(String, TableName, boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Create a new table by cloning the snapshot content.
cloneSnapshot(String, TableName, boolean, String) - Method in interface org.apache.hadoop.hbase.client.Admin
Create a new table by cloning the snapshot content.
cloneSnapshot(String, TableName, boolean, String) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Create a new table by cloning the snapshot content.
cloneSnapshotAsync(String, TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
Create a new table by cloning the snapshot content, but does not block and wait for it to be completely cloned.
cloneSnapshotAsync(String, TableName, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
Create a new table by cloning the snapshot content.
cloneSnapshotAsync(String, TableName, boolean, String) - Method in interface org.apache.hadoop.hbase.client.Admin
Create a new table by cloning the snapshot content.
cloneSnapshotAsync(String, TableName, boolean, String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
cloneTableSchema(TableName, TableName, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
Create a new table by cloning the existent table schema.
cloneTableSchema(TableName, TableName, boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Create a new table by cloning the existent table schema.
cloneTableSchema(TableName, TableName, boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
cloneTags() - Method in interface org.apache.hadoop.hbase.RawCell
Allows cloning the tags in the cell to a new byte[]
cloneTags(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
Deprecated.
As of HBase-2.0. Will be removed in HBase-3.0. Use RawCell.cloneTags()
cloneTags(Cell) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
 
cloneValue(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
 
cloneValue(Tag) - Static method in interface org.apache.hadoop.hbase.Tag
Returns tag value in a new byte array.
close() - Method in class org.apache.hadoop.hbase.chaos.ChaosAgent
 
close() - Method in class org.apache.hadoop.hbase.client.RpcConnectionRegistry
 
close() - Method in interface org.apache.hadoop.hbase.client.Admin
 
close() - Method in interface org.apache.hadoop.hbase.client.AsyncBufferedMutator
Performs a AsyncBufferedMutator.flush() and releases any resources held.
close() - Method in class org.apache.hadoop.hbase.client.AsyncConnectionImpl
 
close() - Method in interface org.apache.hadoop.hbase.client.BufferedMutator
Performs a BufferedMutator.flush() and releases any resources held.
close() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorImpl
 
close() - Method in class org.apache.hadoop.hbase.client.ClientAsyncPrefetchScanner
 
close() - Method in class org.apache.hadoop.hbase.client.ClientScanner
 
close() - Method in class org.apache.hadoop.hbase.client.ClientSideRegionScanner
 
close() - Method in interface org.apache.hadoop.hbase.client.Connection
 
close() - Method in class org.apache.hadoop.hbase.client.ConnectionImplementation
 
close() - Method in interface org.apache.hadoop.hbase.client.ConnectionRegistry
Closes this instance and releases any system resources associated with it
close() - Method in class org.apache.hadoop.hbase.client.example.RefreshHFilesClient
 
close() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
close() - Method in class org.apache.hadoop.hbase.client.HBaseHbck
 
close() - Method in class org.apache.hadoop.hbase.client.HRegionLocator
close() - Method in class org.apache.hadoop.hbase.client.HTable
 
close() - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer
Deprecated.
Closes the internal Connection.
close() - Method in class org.apache.hadoop.hbase.client.RegionServerRegistry
 
close() - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Deprecated.
 
close() - Method in interface org.apache.hadoop.hbase.client.ResultScanner
Closes the scanner and releases any resources it has allocated
close() - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
close() - Method in interface org.apache.hadoop.hbase.client.Table
Releases any resources held or pending changes in internal buffers.
close() - Method in class org.apache.hadoop.hbase.client.TableSnapshotScanner
 
close() - Method in class org.apache.hadoop.hbase.hbtop.screen.Screen
 
close() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.batch.BatchTerminal
 
close() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.TerminalImpl
 
close() - Method in interface org.apache.hadoop.hbase.io.asyncfs.AsyncFSOutput
Close the file.
close() - Method in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutput
End the current block and complete file at namenode.
close() - Method in class org.apache.hadoop.hbase.io.asyncfs.WrapperAsyncFSOutput
 
close() - Method in class org.apache.hadoop.hbase.io.ByteBufferOutputStream
 
close() - Method in class org.apache.hadoop.hbase.io.ByteBufferWriterOutputStream
 
close() - Method in class org.apache.hadoop.hbase.io.compress.ReusableStreamGzipCodec.ReusableGzipOutputStream
 
close() - Method in class org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultEncodingContext
Releases the compressor this writer uses to compress blocks into the compressor pool.
close() - Method in interface org.apache.hadoop.hbase.io.encoding.HFileBlockEncodingContext
Releases the resources used.
close() - Method in class org.apache.hadoop.hbase.io.FileLink.FileLinkInputStream
 
close() - Method in class org.apache.hadoop.hbase.io.FSDataInputStreamWrapper
CloseClose stream(s) if necessary.
close() - Method in class org.apache.hadoop.hbase.io.hadoopbackport.ThrottledInputStream
 
close() - Method in class org.apache.hadoop.hbase.io.hfile.HFileInfo
 
close() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
 
close() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
 
close() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
Close this HFile scanner and do necessary cleanup.
close() - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterImpl
 
close() - Method in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
close() - Method in interface org.apache.hadoop.hbase.ipc.RpcClient
Stop all threads related to this client.
close() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
 
close() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
 
close() - Method in class org.apache.hadoop.hbase.mapreduce.CellSerialization.CellDeserializer
 
close() - Method in class org.apache.hadoop.hbase.mapreduce.CellSerialization.CellSerializer
 
close() - Method in class org.apache.hadoop.hbase.mapreduce.ExtendedCellSerialization.ExtendedCellDeserializer
 
close() - Method in class org.apache.hadoop.hbase.mapreduce.ExtendedCellSerialization.ExtendedCellSerializer
 
close() - Method in class org.apache.hadoop.hbase.mapreduce.HashTable.TableHash.Reader
 
close() - Method in class org.apache.hadoop.hbase.mapreduce.KeyValueSerialization.KeyValueDeserializer
Deprecated.
 
close() - Method in class org.apache.hadoop.hbase.mapreduce.KeyValueSerialization.KeyValueSerializer
Deprecated.
 
close() - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReader
Closes the split.
close() - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReaderImpl
Closes the split.
close() - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.RecordReader
 
close() - Method in class org.apache.hadoop.hbase.master.ClusterStatusPublisher.MulticastPublisher
 
close() - Method in interface org.apache.hadoop.hbase.master.ClusterStatusPublisher.Publisher
 
close() - Method in class org.apache.hadoop.hbase.mob.CachedMobFile
Decreases the reference of the underlying reader for the mob file.
close() - Method in class org.apache.hadoop.hbase.mob.MobCell
 
close() - Method in class org.apache.hadoop.hbase.mob.MobFile
Closes the underlying reader, but do no evict blocks belonging to this file.
close() - Method in class org.apache.hadoop.hbase.quotas.DefaultOperationQuota
 
close() - Method in class org.apache.hadoop.hbase.quotas.ExceedOperationQuota
 
close() - Method in interface org.apache.hadoop.hbase.quotas.OperationQuota
Cleanup method on operation completion
close() - Method in class org.apache.hadoop.hbase.quotas.QuotaRetriever
 
close() - Method in class org.apache.hadoop.hbase.regionserver.AbstractMemStore
 
close() - Method in class org.apache.hadoop.hbase.regionserver.CompositeImmutableSegment
Closing a segment before it is being discarded
close() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Close down this HRegion.
close() - Method in class org.apache.hadoop.hbase.regionserver.HStore
Close all the readers We don't need to worry about subsequent requests because the Region holds a write lock that will prevent any more reads or writes.
close() - Method in class org.apache.hadoop.hbase.regionserver.ImmutableMemStoreLAB
 
close() - Method in interface org.apache.hadoop.hbase.regionserver.InternalScanner
Closes the scanner and releases any resources it has allocated
close() - Method in class org.apache.hadoop.hbase.regionserver.KeyValueHeap
 
close() - Method in interface org.apache.hadoop.hbase.regionserver.KeyValueScanner
Close the KeyValue scanner.
close() - Method in class org.apache.hadoop.hbase.regionserver.LeaseManager
Shut down this Leases instance.
close() - Method in interface org.apache.hadoop.hbase.regionserver.MemStore
Close the memstore.
close() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreCompactorSegmentsIterator
 
close() - Method in interface org.apache.hadoop.hbase.regionserver.MemStoreLAB
Close instance since it won't be used any more, try to put the chunks back to pool
close() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreLABImpl
Close this instance since it won't be used any more, try to put the chunks back to pool
close() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreMergerSegmentsIterator
 
close() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreSegmentsIterator
 
close() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegion
 
close() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
Close the region's metrics as this region is closing.
close() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionSourceImpl
 
close() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
 
close() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableSource
Close the table's metrics as all the region are closing.
close() - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableSourceImpl
 
close() - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImpl
 
close() - Method in class org.apache.hadoop.hbase.regionserver.MobStoreScanner
 
close() - Method in class org.apache.hadoop.hbase.regionserver.ReversedMobStoreScanner
 
close() - Method in class org.apache.hadoop.hbase.regionserver.Segment
Closing a segment before it is being discarded
close() - Method in class org.apache.hadoop.hbase.regionserver.SegmentScanner
Close the KeyValue scanner.
close() - Method in class org.apache.hadoop.hbase.regionserver.SnapshotSegmentScanner
 
close() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
 
close() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileWriter
 
close() - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
 
close() - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
 
close() - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractProtobufWALReader
 
close() - Method in class org.apache.hadoop.hbase.regionserver.wal.AsyncProtobufLogWriter
 
close() - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogWriter
 
close() - Method in class org.apache.hadoop.hbase.rest.ResultGenerator
 
close() - Method in class org.apache.hadoop.hbase.rest.RowResultGenerator
 
close() - Method in class org.apache.hadoop.hbase.rest.ScannerResultGenerator
 
close() - Method in class org.apache.hadoop.hbase.SharedConnection
 
close() - Method in class org.apache.hadoop.hbase.util.CollectionBackedScanner
 
close() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
Deprecated.
 
close() - Method in class org.apache.hadoop.hbase.util.MultiHConnection
Close the open connections and shutdown the batchpool
close() - Method in class org.apache.hadoop.hbase.util.RegionMover
 
close() - Method in class org.apache.hadoop.hbase.wal.AbstractFSWALProvider
 
close() - Method in class org.apache.hadoop.hbase.wal.AbstractWALRoller
 
close() - Method in class org.apache.hadoop.hbase.wal.BoundedRecoveredHFilesOutputSink
 
close() - Method in class org.apache.hadoop.hbase.wal.OutputSink
 
close() - Method in class org.apache.hadoop.hbase.wal.RegionGroupingProvider
 
close() - Method in interface org.apache.hadoop.hbase.wal.WAL
Caller no longer needs any edits from this WAL.
close() - Method in class org.apache.hadoop.hbase.wal.WALFactory
Shutdown all WALs and clean up any underlying storage.
close() - Method in interface org.apache.hadoop.hbase.wal.WALProvider
shutdown utstanding WALs and clean up any persisted state.
close() - Method in interface org.apache.hadoop.hbase.wal.WALStreamReader
Override to remove the 'throws IOException' as we are just a reader.
close() - Method in interface org.apache.hadoop.hbase.wal.WALTailingReader
Override to remove the 'throws IOException' as we are just a reader.
close() - Method in class org.apache.hadoop.hbase.zookeeper.ReadOnlyZKClient
 
close() - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
 
close() - Method in class org.apache.hadoop.hbase.zookeeper.ZKWatcher
Close the connection to ZooKeeper.
close(boolean) - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
Close method with optional evictOnClose
close(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFilePreadReader
 
close(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileStreamReader
 
close(boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
close(boolean) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileReader
 
close(boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Close this HRegion.
close(boolean, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Close down this HRegion.
close(Reporter) - Method in class org.apache.hadoop.hbase.mapred.TableOutputFormat.TableRecordWriter
 
close(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableOutputFormat.MultiTableRecordWriter
 
close(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputFormat.TableRecordWriter
Closes the writer, in this case flush table commits.
CLOSE_METRIC_PREFIX - Static variable in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
 
CLOSE_WAIT_ABORT - Static variable in class org.apache.hadoop.hbase.regionserver.HRegion
 
CLOSE_WAIT_INTERVAL - Static variable in class org.apache.hadoop.hbase.regionserver.HRegion
 
CLOSE_WAIT_TIME - Static variable in class org.apache.hadoop.hbase.regionserver.HRegion
 
closeAfterLeasesExpire() - Method in class org.apache.hadoop.hbase.regionserver.LeaseManager
Shuts down this lease instance when all outstanding leases expire.
closeAndArchiveCompactedFiles() - Method in class org.apache.hadoop.hbase.regionserver.HStore
Closes and archives the compacted files under this store
closeCompletionService - Variable in class org.apache.hadoop.hbase.wal.OutputSink
 
closeConnection(SimpleServerRpcConnection) - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcServer
Deprecated.
 
closed - Variable in class org.apache.hadoop.hbase.client.ClientScanner
 
closed - Variable in class org.apache.hadoop.hbase.client.ScannerCallable
 
closed - Variable in class org.apache.hadoop.hbase.regionserver.SegmentScanner
 
closed - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
 
CLOSED - Enum constant in enum org.apache.hadoop.hbase.master.RegionState.State
 
closeExecutor - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
 
closeFile(MobFile) - Method in class org.apache.hadoop.hbase.mob.MobFileCache
Closes a mob file.
closeImmediately(Channel) - Static method in class org.apache.hadoop.hbase.util.NettyUnsafeUtils
Directly closes the channel, setting SO_LINGER to 0 and skipping any handlers in the pipeline.
closeInternal() - Method in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
closeInternal() - Method in class org.apache.hadoop.hbase.ipc.BlockingRpcClient
 
closeInternal() - Method in class org.apache.hadoop.hbase.ipc.NettyRpcClient
 
closeOutputIfNecessary() - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractProtobufLogWriter
It is straight forward to close the output, do not need to write trailer like the Writer.close
closeOutputIfNecessary() - Method in class org.apache.hadoop.hbase.regionserver.wal.AsyncProtobufLogWriter
 
closeOutputIfNecessary() - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogWriter
 
closeOutputStream - Variable in class org.apache.hadoop.hbase.io.hfile.HFileWriterImpl
True if we opened the outputStream (and so will close it).
closeRegion(byte[], String) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use Admin.unassign(byte[], boolean).
closeRegion(byte[], String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Deprecated.
closeRegion(String, boolean, ServerName) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
Close asynchronously a region, can be called from the master or internally by the regionserver when stopping.
closeRegion(String, String) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use Admin.unassign(byte[], boolean).
closeRegion(String, String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Deprecated.
closeRegion(ServerName, HRegionInfo) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 (HBASE-18231). Use Admin.unassign(byte[], boolean).
closeRegion(ServerName, HRegionInfo) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Deprecated.
closeRegion(RpcController, AdminProtos.AdminService.BlockingInterface, ServerName, byte[]) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
A helper to close a region given a region name using admin protocol.
closeRegion(RpcController, AdminProtos.CloseRegionRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
Close a region on the region server.
closeRegionOperation() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
closeRegionOperation() - Method in interface org.apache.hadoop.hbase.regionserver.Region
Closes the region operation lock.
closeRegionOperation(Region.Operation) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
closeRegionOperation(Region.Operation) - Method in interface org.apache.hadoop.hbase.regionserver.Region
Closes the region operation lock.
closeRegionSilentlyAndWait(ClusterConnection, ServerName, RegionInfo, long) - Static method in class org.apache.hadoop.hbase.master.ServerManager
Contacts a region server and waits up to timeout ms to close the region.
closeRegionSilentlyAndWait(Connection, ServerName, RegionInfo) - Static method in class org.apache.hadoop.hbase.util.HBaseFsckRepair
Contacts a region server and waits up to hbase.hbck.close.timeout ms (default 120s) to close the region.
closeRegionWithEncodedRegionName(String, String) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use Admin.unassign(byte[], boolean).
closeRegionWithEncodedRegionName(String, String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Deprecated.
closeStoreFile(boolean) - Method in class org.apache.hadoop.hbase.regionserver.HStoreFile
 
closeTable() - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
Close the Table and related objects that were initialized via TableInputFormatBase.initializeTable(Connection, TableName).
closeTable() - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
Close the Table and related objects that were initialized via TableInputFormatBase.initializeTable(Connection, TableName).
closeThreadPool - Variable in class org.apache.hadoop.hbase.wal.OutputSink
Used when close this output sink.
CLOSING - Enum constant in enum org.apache.hadoop.hbase.master.RegionState.State
 
org.apache.hadoop.hbase.rest.client.Cluster - Class in org.apache.hadoop.hbase.rest.client
A list of 'host:port' addresses of HTTP servers operating as a single entity, for example multiple redundant web service gateways.
Cluster() - Constructor for class org.apache.hadoop.hbase.rest.client.Cluster
Constructor
Cluster(List<String>) - Constructor for class org.apache.hadoop.hbase.rest.client.Cluster
Constructor
CLUSTER - Enum constant in enum org.apache.hadoop.hbase.quotas.QuotaScope
The specified throttling rules will be applied at the cluster level.
CLUSTER_DISTRIBUTED - Static variable in class org.apache.hadoop.hbase.HConstants
Cluster is in distributed mode or not
CLUSTER_ID - Enum constant in enum org.apache.hadoop.hbase.ClusterMetrics.Option
metrics about cluster id
CLUSTER_ID_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
Default value for cluster ID
CLUSTER_ID_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
 
CLUSTER_ID_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
CLUSTER_ID_FILE_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
name of the file for unique cluster ID
CLUSTER_ID_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
 
CLUSTER_ID_NAME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
CLUSTER_IS_DISTRIBUTED - Static variable in class org.apache.hadoop.hbase.HConstants
Deprecated.
CLUSTER_IS_LOCAL - Static variable in class org.apache.hadoop.hbase.HConstants
Cluster is standalone or pseudo-distributed
CLUSTER_REQUESTS_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
 
clusterCompactionQueues - Variable in class org.apache.hadoop.hbase.util.compaction.MajorCompactor
 
clusterConnection - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
Cluster connection to be shared by services.
org.apache.hadoop.hbase.client.ClusterConnection - Interface in org.apache.hadoop.hbase.client
Internal methods on Connection that should not be used by user code.
clusterId - Variable in class org.apache.hadoop.hbase.client.ConnectionImplementation
 
clusterId - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
clusterId - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
Unique identifier for the cluster we are a part of.
org.apache.hadoop.hbase.ClusterId - Class in org.apache.hadoop.hbase
The identifier for this cluster.
ClusterId() - Constructor for class org.apache.hadoop.hbase.ClusterId
New ClusterID.
ClusterId(String) - Constructor for class org.apache.hadoop.hbase.ClusterId
 
clusterIdZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZNodePaths
 
org.apache.hadoop.hbase.replication.ClusterMarkingEntryFilter - Class in org.apache.hadoop.hbase.replication
Filters out entries with our peerClusterId (i.e.
ClusterMarkingEntryFilter(UUID, UUID, ReplicationEndpoint) - Constructor for class org.apache.hadoop.hbase.replication.ClusterMarkingEntryFilter
 
org.apache.hadoop.hbase.ClusterMetrics - Interface in org.apache.hadoop.hbase
Metrics information on the HBase cluster.
org.apache.hadoop.hbase.ClusterMetrics.Option - Enum in org.apache.hadoop.hbase
Kinds of ClusterMetrics
org.apache.hadoop.hbase.ClusterMetricsBuilder - Class in org.apache.hadoop.hbase
 
org.apache.hadoop.hbase.master.ClusterSchema - Interface in org.apache.hadoop.hbase.master
View and edit the current cluster schema.
org.apache.hadoop.hbase.master.ClusterSchemaService - Interface in org.apache.hadoop.hbase.master
Mixes in ClusterSchema and Service
clusterStateZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZNodePaths
 
org.apache.hadoop.hbase.ClusterStatus - Class in org.apache.hadoop.hbase
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use ClusterMetrics instead.
ClusterStatus(String, String, Map<ServerName, ServerLoad>, Collection<ServerName>, ServerName, Collection<ServerName>, List<RegionState>, String[], Boolean, int) - Constructor for class org.apache.hadoop.hbase.ClusterStatus
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0
ClusterStatus(ClusterMetrics) - Constructor for class org.apache.hadoop.hbase.ClusterStatus
Deprecated.
 
org.apache.hadoop.hbase.master.ClusterStatusPublisher - Class in org.apache.hadoop.hbase.master
Class to publish the cluster status to the client.
ClusterStatusPublisher() - Constructor for class org.apache.hadoop.hbase.master.ClusterStatusPublisher
 
ClusterStatusPublisher(HMaster, Configuration, Class<? extends ClusterStatusPublisher.Publisher>) - Constructor for class org.apache.hadoop.hbase.master.ClusterStatusPublisher
 
org.apache.hadoop.hbase.master.ClusterStatusPublisher.MulticastPublisher - Class in org.apache.hadoop.hbase.master
 
org.apache.hadoop.hbase.master.ClusterStatusPublisher.Publisher - Interface in org.apache.hadoop.hbase.master
 
clusterStatusTracker - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
org.apache.hadoop.hbase.zookeeper.ClusterStatusTracker - Class in org.apache.hadoop.hbase.zookeeper
Tracker on cluster settings up in zookeeper.
ClusterStatusTracker(ZKWatcher, Abortable) - Constructor for class org.apache.hadoop.hbase.zookeeper.ClusterStatusTracker
Creates a cluster status tracker.
cmdLineArgs - Variable in class org.apache.hadoop.hbase.util.AbstractHBaseTool
 
cmp(int) - Method in enum org.apache.hadoop.hbase.util.Order
Returns the adjusted trichotomous value according to the ordering imposed by this Order.
COALESCE_INC_KEY - Static variable in class org.apache.hadoop.hbase.thrift.Constants
 
code - Variable in enum org.apache.hadoop.hbase.security.AuthMethod
The code for this method.
codec - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
org.apache.hadoop.hbase.codec.Codec - Interface in org.apache.hadoop.hbase.codec
Encoder/Decoder for Cell.
org.apache.hadoop.hbase.codec.Codec.Decoder - Interface in org.apache.hadoop.hbase.codec
Implementations should implicitly clean up any resources allocated when the Decoder/CellScanner runs off the end of the cell block.
org.apache.hadoop.hbase.codec.Codec.Encoder - Interface in org.apache.hadoop.hbase.codec
Call flush when done.
codecClsName - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractProtobufWALReader
 
org.apache.hadoop.hbase.codec.CodecException - Exception in org.apache.hadoop.hbase.codec
Thrown when problems in the codec whether setup or context.
CodecException() - Constructor for exception org.apache.hadoop.hbase.codec.CodecException
 
CodecException(String) - Constructor for exception org.apache.hadoop.hbase.codec.CodecException
 
CodecException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.codec.CodecException
 
CodecException(Throwable) - Constructor for exception org.apache.hadoop.hbase.codec.CodecException
 
codeToType(byte) - Static method in enum org.apache.hadoop.hbase.KeyValue.Type
Cannot rely on enum ordinals .
codeToType(byte) - Static method in enum org.apache.hadoop.hbase.util.ChecksumType
Cannot rely on enum ordinals .
colDescFromHbase(HColumnDescriptor) - Static method in class org.apache.hadoop.hbase.thrift.ThriftUtilities
This utility method creates a new Thrift ColumnDescriptor "struct" based on an Hbase HColumnDescriptor object.
colDescFromThrift(ColumnDescriptor) - Static method in class org.apache.hadoop.hbase.thrift.ThriftUtilities
This utility method creates a new Hbase HColumnDescriptor object based on a Thrift ColumnDescriptor "struct".
colFamTimeRangeMap - Variable in class org.apache.hadoop.hbase.client.Query
 
org.apache.hadoop.hbase.util.CollectionBackedScanner - Class in org.apache.hadoop.hbase.util
Utility scanner that wraps a sortable collection and serves as a KeyValueScanner.
CollectionBackedScanner(List<Cell>) - Constructor for class org.apache.hadoop.hbase.util.CollectionBackedScanner
 
CollectionBackedScanner(List<Cell>, CellComparator) - Constructor for class org.apache.hadoop.hbase.util.CollectionBackedScanner
 
CollectionBackedScanner(SortedSet<Cell>) - Constructor for class org.apache.hadoop.hbase.util.CollectionBackedScanner
 
CollectionBackedScanner(SortedSet<Cell>, CellComparator) - Constructor for class org.apache.hadoop.hbase.util.CollectionBackedScanner
 
CollectionBackedScanner(CellComparator, Cell...) - Constructor for class org.apache.hadoop.hbase.util.CollectionBackedScanner
 
org.apache.hadoop.hbase.util.CollectionUtils - Class in org.apache.hadoop.hbase.util
Deprecated.
Since 2.0.6/2.1.3/2.2.0
CollectionUtils() - Constructor for class org.apache.hadoop.hbase.util.CollectionUtils
Deprecated.
 
COLON - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for colon (:)
color(Color, Color, boolean, boolean, boolean, boolean) - Static method in class org.apache.hadoop.hbase.hbtop.terminal.impl.EscapeSequences
 
org.apache.hadoop.hbase.hbtop.terminal.Color - Enum in org.apache.hadoop.hbase.hbtop.terminal
Terminal color definitions.
COLUMN_DELETED - Enum constant in enum org.apache.hadoop.hbase.regionserver.querymatcher.DeleteTracker.DeleteResult
 
COLUMN_FAMILY_DELIM_ARRAY - Static variable in class org.apache.hadoop.hbase.KeyValue
 
COLUMN_FAMILY_DELIMITER - Static variable in class org.apache.hadoop.hbase.KeyValue
Colon character in UTF-8
COLUMN_LIST - Static variable in class org.apache.hadoop.hbase.mapred.TableInputFormat
space delimited list of columns
org.apache.hadoop.hbase.filter.ColumnCountGetFilter - Class in org.apache.hadoop.hbase.filter
Simple filter that returns first N columns on row only.
ColumnCountGetFilter(int) - Constructor for class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
 
columnFamily - Variable in class org.apache.hadoop.hbase.filter.DependentColumnFilter
 
columnFamily - Variable in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
org.apache.hadoop.hbase.client.ColumnFamilyDescriptor - Interface in org.apache.hadoop.hbase.client
An ColumnFamilyDescriptor contains information about a column family such as the number of versions, compression settings, etc.
org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder - Class in org.apache.hadoop.hbase.client
 
org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor - Class in org.apache.hadoop.hbase.client
An ModifyableFamilyDescriptor contains information about a column family such as the number of versions, compression settings, etc.
org.apache.hadoop.hbase.coprocessor.ColumnInterpreter<T,S,P extends com.google.protobuf.Message,Q extends com.google.protobuf.Message,R extends com.google.protobuf.Message> - Class in org.apache.hadoop.hbase.coprocessor
Defines how value for specific column is interpreted and provides utility methods like compare, add, multiply etc for them.
ColumnInterpreter() - Constructor for class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
 
org.apache.hadoop.hbase.filter.ColumnPaginationFilter - Class in org.apache.hadoop.hbase.filter
A filter, based on the ColumnCountGetFilter, takes two arguments: limit and offset.
ColumnPaginationFilter(int, byte[]) - Constructor for class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
Initializes filter with a string/bookmark based offset and limit.
ColumnPaginationFilter(int, int) - Constructor for class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
Initializes filter with an integer offset and limit.
org.apache.hadoop.hbase.filter.ColumnPrefixFilter - Class in org.apache.hadoop.hbase.filter
This filter is used for selecting only those keys with columns that matches a particular prefix.
ColumnPrefixFilter(byte[]) - Constructor for class org.apache.hadoop.hbase.filter.ColumnPrefixFilter
 
columnQualifier - Variable in class org.apache.hadoop.hbase.filter.DependentColumnFilter
 
columnQualifier - Variable in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
org.apache.hadoop.hbase.filter.ColumnRangeFilter - Class in org.apache.hadoop.hbase.filter
This filter is used for selecting only those keys with columns that are between minColumn to maxColumn.
ColumnRangeFilter(byte[], boolean, byte[], boolean) - Constructor for class org.apache.hadoop.hbase.filter.ColumnRangeFilter
Create a filter to select those keys with columns that are between minColumn and maxColumn.
columns - Variable in class org.apache.hadoop.hbase.mapred.GroupingTableMap
 
columns - Variable in class org.apache.hadoop.hbase.mapreduce.GroupingTableMapper
The grouping columns.
columns - Variable in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher
Keeps track of columns and versions
COLUMNS_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv
 
org.apache.hadoop.hbase.regionserver.querymatcher.ColumnTracker - Interface in org.apache.hadoop.hbase.regionserver.querymatcher
Implementing classes of this interface will be used for the tracking and enforcement of columns and numbers of versions and timeToLive during the course of a Get or Scan operation.
org.apache.hadoop.hbase.filter.ColumnValueFilter - Class in org.apache.hadoop.hbase.filter
Different from SingleColumnValueFilter which returns an entire row when specified condition is matched, ColumnValueFilter return the matched cell only.
ColumnValueFilter(byte[], byte[], CompareOperator, byte[]) - Constructor for class org.apache.hadoop.hbase.filter.ColumnValueFilter
 
ColumnValueFilter(byte[], byte[], CompareOperator, ByteArrayComparable) - Constructor for class org.apache.hadoop.hbase.filter.ColumnValueFilter
 
combine(Record) - Method in class org.apache.hadoop.hbase.hbtop.Record
 
org.apache.hadoop.hbase.io.hfile.CombinedBlockCache - Class in org.apache.hadoop.hbase.io.hfile
CombinedBlockCache is an abstraction layer that combines FirstLevelBlockCache and BucketCache.
CombinedBlockCache(FirstLevelBlockCache, BlockCache) - Constructor for class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
 
org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats - Class in org.apache.hadoop.hbase.io.hfile
 
combinedCacheStats - Variable in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
 
combineTableNameSuffix(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
 
COMMA - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for a comma
org.apache.hadoop.hbase.hbtop.screen.help.CommandDescription - Class in org.apache.hadoop.hbase.hbtop.screen.help
Represents a description of a command that we can execute in the top screen.
CommandDescription(String, String) - Constructor for class org.apache.hadoop.hbase.hbtop.screen.help.CommandDescription
 
CommandDescription(List<String>, String) - Constructor for class org.apache.hadoop.hbase.hbtop.screen.help.CommandDescription
 
commitDaughterRegion(RegionInfo, List<Path>, MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
Commit a daughter region, moving it from the split temporary directory to the proper location in the filesystem.
commitFile(Path, Path) - Method in class org.apache.hadoop.hbase.regionserver.HMobStore
Commits the mob file.
commitMergedRegion(List<Path>, MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
Commit a merged region, making it ready for use.
commitStoreFile(String, Path) - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
Move the file from a build/temp location to the main family store directory.
commitStoreFiles(List<Path>, boolean) - Method in class org.apache.hadoop.hbase.regionserver.StoreEngine
Commit the given files.
commitTask(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputCommitter
 
commitWriter(StoreFileWriter, Compactor.FileDetails, CompactionRequestImpl) - Method in class org.apache.hadoop.hbase.mob.DefaultMobStoreCompactor
 
commitWriters(long, boolean) - Method in class org.apache.hadoop.hbase.regionserver.AbstractMultiFileWriter
Commit all writers.
commitWriters(long, boolean, Collection<HStoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.AbstractMultiFileWriter
 
org.apache.hadoop.hbase.util.CommonFSUtils - Class in org.apache.hadoop.hbase.util
Utility methods for interacting with the underlying file system.
org.apache.hadoop.hbase.util.CommonFSUtils.StreamLacksCapabilityException - Exception in org.apache.hadoop.hbase.util
Helper exception for those cases where the place where we need to check a stream capability is not where we have the needed context to explain the impact and mitigation for a lack.
org.apache.hadoop.hbase.io.crypto.aes.CommonsCryptoAES - Class in org.apache.hadoop.hbase.io.crypto.aes
 
CommonsCryptoAES(CipherProvider) - Constructor for class org.apache.hadoop.hbase.io.crypto.aes.CommonsCryptoAES
 
org.apache.hadoop.hbase.io.crypto.aes.CommonsCryptoAESDecryptor - Class in org.apache.hadoop.hbase.io.crypto.aes
 
CommonsCryptoAESDecryptor(String, Properties) - Constructor for class org.apache.hadoop.hbase.io.crypto.aes.CommonsCryptoAESDecryptor
 
org.apache.hadoop.hbase.io.crypto.aes.CommonsCryptoAESEncryptor - Class in org.apache.hadoop.hbase.io.crypto.aes
 
CommonsCryptoAESEncryptor(String, Properties, SecureRandom) - Constructor for class org.apache.hadoop.hbase.io.crypto.aes.CommonsCryptoAESEncryptor
 
compact(boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Synchronously compact all stores in the region.
compact(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
 
compact(CompactionContext, HStore, ThroughputController) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Called by compaction thread and after region is opened to compact the HStores if necessary.
compact(CompactionContext, HStore, ThroughputController, User) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
compact(CompactionContext, ThroughputController, User) - Method in class org.apache.hadoop.hbase.regionserver.HStore
Compact the StoreFiles.
compact(CompactionRequestImpl, ThroughputController, User) - Method in class org.apache.hadoop.hbase.mob.DefaultMobStoreCompactor
 
compact(VersionedSegmentsList, String) - Method in class org.apache.hadoop.hbase.regionserver.MemStoreCompactionStrategy
 
compact(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
Compact a table.
compact(TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Compact a table.
compact(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Compact a table.
compact(TableName, byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
Compact a column family within a table.
compact(TableName, byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Compact a column family within a table.
compact(TableName, byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Compact a column family within a table.
compact(TableName, byte[], CompactType) - Method in interface org.apache.hadoop.hbase.client.Admin
Compact a column family within a table.
compact(TableName, byte[], CompactType) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Compact a column family within a table.
compact(TableName, byte[], CompactType) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Compact a column family within a table.
compact(TableName, CompactType) - Method in interface org.apache.hadoop.hbase.client.Admin
Compact a table.
compact(TableName, CompactType) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Compact a table.
compact(TableName, CompactType) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Compact a table.
COMPACT - Enum constant in enum org.apache.hadoop.hbase.regionserver.MemStoreCompactionStrategy.Action
 
COMPACT_CONF_DEFAULT - Static variable in class org.apache.hadoop.hbase.thrift.Constants
 
COMPACT_CONF_KEY - Static variable in class org.apache.hadoop.hbase.thrift.Constants
 
COMPACT_DROP_DELETES - Enum constant in enum org.apache.hadoop.hbase.regionserver.ScanType
 
COMPACT_OPTION - Static variable in class org.apache.hadoop.hbase.thrift.Constants
 
COMPACT_REGION - Enum constant in enum org.apache.hadoop.hbase.regionserver.Region.Operation
 
COMPACT_RETAIN_DELETES - Enum constant in enum org.apache.hadoop.hbase.regionserver.ScanType
 
COMPACT_SWITCH - Enum constant in enum org.apache.hadoop.hbase.regionserver.Region.Operation
 
compactAllRegions() - Method in class org.apache.hadoop.hbase.util.compaction.MajorCompactor
 
compactBloom() - Method in class org.apache.hadoop.hbase.io.hfile.CompoundBloomFilterWriter
 
compactBloom() - Method in class org.apache.hadoop.hbase.util.BloomFilterChunk
 
compactBloom() - Method in interface org.apache.hadoop.hbase.util.BloomFilterWriter
Compact the Bloom filter before writing metadata & data to disk.
COMPACTCHECKER_INTERVAL_MULTIPLIER_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.HStore
 
COMPACTED_CELL_COUNT - Enum constant in enum org.apache.hadoop.hbase.hbtop.field.Field
 
COMPACTED_CELLS - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
COMPACTED_CELLS_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
COMPACTED_CELLS_SIZE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
COMPACTED_CELLS_SIZE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
COMPACTED_INPUT_BYTES - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
COMPACTED_INPUT_BYTES_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
COMPACTED_OUTPUT_BYTES - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
COMPACTED_OUTPUT_BYTES_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
org.apache.hadoop.hbase.regionserver.CompactedHFilesDischargeHandler - Class in org.apache.hadoop.hbase.regionserver
Event handler that handles the removal and archival of the compacted hfiles
CompactedHFilesDischargeHandler(Server, EventType, HStore) - Constructor for class org.apache.hadoop.hbase.regionserver.CompactedHFilesDischargeHandler
 
org.apache.hadoop.hbase.regionserver.CompactedHFilesDischarger - Class in org.apache.hadoop.hbase.regionserver
A chore service that periodically cleans up the compacted files when there are no active readers using those compacted files and also helps in clearing the block cache of these compacted file entries.
CompactedHFilesDischarger(int, Stoppable, RegionServerServices) - Constructor for class org.apache.hadoop.hbase.regionserver.CompactedHFilesDischarger
 
CompactedHFilesDischarger(int, Stoppable, RegionServerServices, boolean) - Constructor for class org.apache.hadoop.hbase.regionserver.CompactedHFilesDischarger
 
COMPACTING_CELL_COUNT - Enum constant in enum org.apache.hadoop.hbase.hbtop.field.Field
 
COMPACTING_MEMSTORE_THRESHOLD_DEFAULT - Static variable in class org.apache.hadoop.hbase.regionserver.MemStoreCompactionStrategy
 
COMPACTING_MEMSTORE_THRESHOLD_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.MemStoreCompactionStrategy
 
COMPACTING_MEMSTORE_TYPE_DEFAULT - Static variable in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
 
COMPACTING_MEMSTORE_TYPE_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
 
org.apache.hadoop.hbase.regionserver.CompactingMemStore - Class in org.apache.hadoop.hbase.regionserver
A memstore implementation which supports in-memory compaction.
CompactingMemStore(Configuration, CellComparator, HStore, RegionServicesForStores, MemoryCompactionPolicy) - Constructor for class org.apache.hadoop.hbase.regionserver.CompactingMemStore
 
org.apache.hadoop.hbase.regionserver.CompactingMemStore.IndexType - Enum in org.apache.hadoop.hbase.regionserver
Types of indexes (part of immutable segments) to be used after flattening, compaction, or merge are applied.
COMPACTION - Static variable in class org.apache.hadoop.hbase.wal.WALEdit
Deprecated.
Since 2.3.0. Make it protected, internal-use only. Use WALEdit.isCompactionMarker(Cell)
COMPACTION_AFTER_BULKLOAD_ENABLE - Static variable in class org.apache.hadoop.hbase.regionserver.HRegion
Parameter name for compaction after bulkload
COMPACTION_ENABLED - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
Used by HBase Shell interface to access this metadata attribute which denotes if the table is compaction enabled.
COMPACTION_ENABLED - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
 
COMPACTION_EVENT_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.HStoreFile
Key for compaction event which contains the compacted storefiles in FileInfo
COMPACTION_INPUT_FILE_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
COMPACTION_INPUT_FILE_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
COMPACTION_INPUT_SIZE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
COMPACTION_INPUT_SIZE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
COMPACTION_KV_MAX - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for the maximum batch of KVs to be used in flushes and compactions
COMPACTION_KV_MAX_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
 
COMPACTION_OUTPUT_FILE_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
COMPACTION_OUTPUT_FILE_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
COMPACTION_OUTPUT_SIZE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
COMPACTION_OUTPUT_SIZE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
COMPACTION_PROGRESS - Enum constant in enum org.apache.hadoop.hbase.hbtop.field.Field
 
COMPACTION_QUEUE_LENGTH - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
COMPACTION_QUEUE_LENGTH_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
COMPACTION_SCANNER_SIZE_MAX - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for the scanner size limit to be used in compactions
COMPACTION_SCANNER_SIZE_MAX_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
 
COMPACTION_TIME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
COMPACTION_TIME_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
org.apache.hadoop.hbase.regionserver.CompactionPipeline - Class in org.apache.hadoop.hbase.regionserver
The compaction pipeline of a CompactingMemStore, is a FIFO queue of segments.
CompactionPipeline(RegionServicesForStores) - Constructor for class org.apache.hadoop.hbase.regionserver.CompactionPipeline
 
compactionPolicy - Variable in class org.apache.hadoop.hbase.regionserver.StoreEngine
 
COMPACTIONS_COMPLETED_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
 
COMPACTIONS_COMPLETED_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
 
COMPACTIONS_FAILED_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
 
COMPACTIONS_FAILED_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
 
COMPACTIONS_QUEUED_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
 
COMPACTIONS_QUEUED_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
 
org.apache.hadoop.hbase.regionserver.querymatcher.CompactionScanQueryMatcher - Class in org.apache.hadoop.hbase.regionserver.querymatcher
Query matcher for compaction.
CompactionScanQueryMatcher(ScanInfo, DeleteTracker, ColumnTracker, long, long, long) - Constructor for class org.apache.hadoop.hbase.regionserver.querymatcher.CompactionScanQueryMatcher
 
org.apache.hadoop.hbase.client.CompactionState - Enum in org.apache.hadoop.hbase.client
POJO representing the compaction state
compactionSwitch(boolean, List<String>) - Method in interface org.apache.hadoop.hbase.client.Admin
Turn the compaction on or off.
compactionSwitch(boolean, List<String>) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Turn the compaction on or off.
compactionSwitch(boolean, List<String>) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
compactionSwitch(RpcController, AdminProtos.CompactionSwitchRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
 
org.apache.hadoop.hbase.regionserver.throttle.CompactionThroughputControllerFactory - Class in org.apache.hadoop.hbase.regionserver.throttle
 
org.apache.hadoop.hbase.regionserver.CompactionTool - Class in org.apache.hadoop.hbase.regionserver
 
CompactionTool() - Constructor for class org.apache.hadoop.hbase.regionserver.CompactionTool
 
compactor - Variable in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
 
compactor - Variable in class org.apache.hadoop.hbase.regionserver.StoreEngine
 
compactRegion(byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
Compact an individual region.
compactRegion(byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Compact an individual region.
compactRegion(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
compactRegion(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
Compact a column family within a region.
compactRegion(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Compact a column family within a region.
compactRegion(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Compact a column family within a region.
compactRegion(RpcController, AdminProtos.CompactRegionRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
Compact a region on the master.
compactRegion(RpcController, AdminProtos.CompactRegionRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
Compact a region on the region server.
compactRegionServer(ServerName) - Method in interface org.apache.hadoop.hbase.client.Admin
Compact all regions on the region server.
compactRegionServer(ServerName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Compact all regions on the region server.
compactRegionServer(ServerName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
compactRegionServer(ServerName, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use Admin.compactRegionServer(ServerName) or Admin.majorCompactRegionServer(ServerName).
compactRegionsTTLOnTable(Configuration, String, int, long, int, int, boolean, boolean) - Method in class org.apache.hadoop.hbase.util.compaction.MajorCompactorTTL
 
org.apache.hadoop.hbase.regionserver.CompactSplit - Class in org.apache.hadoop.hbase.regionserver
Compact region on request and then run split if appropriate
CompactSplit(Configuration) - Constructor for class org.apache.hadoop.hbase.regionserver.CompactSplit
 
org.apache.hadoop.hbase.regionserver.CompactSplit.CompactionCompleteTracker - Interface in org.apache.hadoop.hbase.regionserver
 
compactStores() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
This is a helper function that compact all the stores synchronously.
compactTTLRegionsOnGroup(Configuration, String, int, long, int, int, boolean, boolean) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupMajorCompactionTTL
 
org.apache.hadoop.hbase.client.CompactType - Enum in org.apache.hadoop.hbase.client
Currently, there are only two compact types: NORMAL means do store files compaction; MOB means do mob files compaction.
comparator - Variable in class org.apache.hadoop.hbase.filter.CompareFilter
 
comparator - Variable in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
comparator - Variable in class org.apache.hadoop.hbase.io.hfile.CompoundBloomFilterBase
Comparator used to compare Bloom filter keys
comparator - Variable in class org.apache.hadoop.hbase.regionserver.KeyValueHeap
 
comparator - Variable in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanDeleteTracker
 
comparator - Variable in class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter
 
comparator - Variable in class org.apache.hadoop.hbase.regionserver.StripeStoreFlusher.StripeFlushRequest
 
comparator - Variable in class org.apache.hadoop.hbase.util.BloomContext
 
comparator() - Method in class org.apache.hadoop.hbase.io.hfile.HFileInfo
 
comparator() - Method in class org.apache.hadoop.hbase.regionserver.CellFlatMap
 
comparator() - Method in class org.apache.hadoop.hbase.regionserver.CellSet
 
comparator() - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
 
comparator() - Method in class org.apache.hadoop.hbase.util.BoundedPriorityBlockingQueue
 
Comparator() - Constructor for class org.apache.hadoop.hbase.io.ImmutableBytesWritable.Comparator
 
COMPARATOR - Static variable in class org.apache.hadoop.hbase.CellComparatorImpl
Comparator for plain key/values; i.e.
COMPARATOR - Static variable in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
 
COMPARATOR - Static variable in interface org.apache.hadoop.hbase.client.RegionInfo
 
COMPARATOR - Static variable in interface org.apache.hadoop.hbase.client.Row
 
COMPARATOR - Static variable in interface org.apache.hadoop.hbase.client.TableDescriptor
 
COMPARATOR - Static variable in class org.apache.hadoop.hbase.KeyValue
Deprecated.
Use CellComparator.getInstance() instead. Deprecated for hbase 2.0, remove for hbase 3.0.
COMPARATOR_IGNORE_REPLICATION - Static variable in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
 
COMPARATOR_IGNORE_REPLICATION - Static variable in interface org.apache.hadoop.hbase.client.TableDescriptor
 
compare(byte[], byte[]) - Method in class org.apache.hadoop.hbase.util.Bytes.ByteArrayComparator
 
compare(byte[], byte[]) - Method in class org.apache.hadoop.hbase.util.Bytes.RowEndKeyComparator
 
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable.Comparator
 
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
Deprecated.
 
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.mapreduce.Import.CellWritableComparable.CellWritableComparator
 
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.mapreduce.Import.KeyValueWritableComparable.KeyValueWritableComparator
 
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.util.Bytes.ByteArrayComparator
 
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.util.Bytes.RowEndKeyComparator
 
compare(long) - Method in class org.apache.hadoop.hbase.io.TimeRange
Compare the timestamp to timerange.
compare(Path, Path) - Method in class org.apache.hadoop.hbase.wal.AbstractFSWALProvider.WALStartTimeComparator
 
compare(CellComparator, Cell, byte[], int, int) - Static method in class org.apache.hadoop.hbase.CellUtil
Deprecated.
As of HBase-2.0. Will be removed in HBase-3.0
compare(CellComparator, Cell, byte[], int, int) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
Used when a cell needs to be compared with a key byte[] such as cases of finding the index from the index block, bloom keys from the bloom blocks This byte[] is expected to be serialized in the KeyValue serialization format If the KeyValue (Cell's) serialization format changes this method cannot be used.
compare(Cell, Cell) - Method in interface org.apache.hadoop.hbase.CellComparator
Lexographically compares two cells.
compare(Cell, Cell) - Method in class org.apache.hadoop.hbase.CellComparatorImpl
 
compare(Cell, Cell) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
Deprecated.
Compares the Key of a cell -- with fields being more significant in this order: rowkey, colfam/qual, timestamp, type, mvcc
compare(Cell, Cell) - Method in class org.apache.hadoop.hbase.KeyValue.MetaComparator
Deprecated.
Compare key portion of a KeyValue for keys in hbase:meta table.
compare(Cell, Cell) - Method in class org.apache.hadoop.hbase.regionserver.CompositeImmutableSegment
 
compare(Cell, Cell) - Method in class org.apache.hadoop.hbase.regionserver.KeyValueHeap.KVScannerComparator
Compares two KeyValue
compare(Cell, Cell) - Method in class org.apache.hadoop.hbase.regionserver.Segment
 
compare(Cell, Cell, boolean) - Method in interface org.apache.hadoop.hbase.CellComparator
Compare cells.
compare(Cell, Cell, boolean) - Method in class org.apache.hadoop.hbase.CellComparatorImpl
 
compare(Cell, Cell, boolean) - Method in class org.apache.hadoop.hbase.MetaCellComparator
 
compare(HDFSBlocksDistribution.HostAndWeight, HDFSBlocksDistribution.HostAndWeight) - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution.HostAndWeight.WeightComparator
 
compare(RegionPlan, RegionPlan) - Method in class org.apache.hadoop.hbase.master.RegionPlan.RegionPlanComparator
 
compare(KeyValueScanner, KeyValueScanner) - Method in class org.apache.hadoop.hbase.regionserver.KeyValueHeap.KVScannerComparator
 
compare(Option, Option) - Method in class org.apache.hadoop.hbase.util.AbstractHBaseTool.OptionsOrderComparator
 
compare(T, T) - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
This takes care if either of arguments are null.
compareAndSetDataSize(long, long) - Method in interface org.apache.hadoop.hbase.regionserver.MemStoreSizing
 
compareAndSetDataSize(long, long) - Method in class org.apache.hadoop.hbase.regionserver.Segment
 
compareAndSetMax(long, long) - Method in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker
 
compareAndSetMax(long, long) - Method in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker.NonSyncTimeRangeTracker
 
compareAndSetMax(long, long) - Method in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker.SyncTimeRangeTracker
 
compareAndSetMin(long, long) - Method in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker
 
compareAndSetMin(long, long) - Method in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker.NonSyncTimeRangeTracker
 
compareAndSetMin(long, long) - Method in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker.SyncTimeRangeTracker
 
compareCell(Cell, Cell) - Method in class org.apache.hadoop.hbase.filter.FilterListBase
 
compareColumns(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
Deprecated.
 
compareColumns(byte[], int, int, int, byte[], int, int, int) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
Deprecated.
 
compareColumns(Cell, byte[], int, int, int, int) - Static method in class org.apache.hadoop.hbase.CellUtil
Compares the cell's column (family and qualifier) with the given byte[]
compareColumns(Cell, Cell) - Method in class org.apache.hadoop.hbase.CellComparatorImpl
Compares the family and qualifier part of the cell
compareCommonFamilyPrefix(Cell, Cell, int) - Static method in class org.apache.hadoop.hbase.io.encoding.CopyKeyDataBlockEncoder
 
compareCommonQualifierPrefix(Cell, Cell, int) - Static method in class org.apache.hadoop.hbase.io.encoding.CopyKeyDataBlockEncoder
 
compareCommonRowPrefix(Cell, Cell, int) - Static method in class org.apache.hadoop.hbase.io.encoding.CopyKeyDataBlockEncoder
common prefixes
compareFamilies(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
Deprecated.
 
compareFamilies(ByteBufferKeyValue, int, int, ByteBufferKeyValue, int, int) - Method in class org.apache.hadoop.hbase.CellComparatorImpl
This method will be overridden when we compare cells inner store to bypass family comparing.
compareFamilies(ByteBufferKeyValue, int, int, ByteBufferKeyValue, int, int) - Method in class org.apache.hadoop.hbase.InnerStoreCellComparator
 
compareFamilies(Cell, byte[], int, int) - Static method in class org.apache.hadoop.hbase.CellUtil
Compares the cell's family with the given byte[]
compareFamilies(Cell, int, Cell, int) - Method in class org.apache.hadoop.hbase.CellComparatorImpl
This method will be overridden when we compare cells inner store to bypass family comparing.
compareFamilies(Cell, int, Cell, int) - Method in class org.apache.hadoop.hbase.InnerStoreCellComparator
 
compareFamilies(Cell, Cell) - Method in interface org.apache.hadoop.hbase.CellComparator
Lexicographically compares the families of the two cells
compareFamilies(Cell, Cell) - Method in class org.apache.hadoop.hbase.CellComparatorImpl
Compare the families of left and right cell
compareFamilies(KeyValue, int, int, ByteBufferKeyValue, int, int) - Method in class org.apache.hadoop.hbase.CellComparatorImpl
This method will be overridden when we compare cells inner store to bypass family comparing.
compareFamilies(KeyValue, int, int, ByteBufferKeyValue, int, int) - Method in class org.apache.hadoop.hbase.InnerStoreCellComparator
 
compareFamilies(KeyValue, int, int, KeyValue, int, int) - Method in class org.apache.hadoop.hbase.CellComparatorImpl
This method will be overridden when we compare cells inner store to bypass family comparing.
compareFamilies(KeyValue, int, int, KeyValue, int, int) - Method in class org.apache.hadoop.hbase.InnerStoreCellComparator
 
compareFamily(Cell, ByteArrayComparable) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
Compare cell's column family against given comparator
compareFamily(CompareOperator, ByteArrayComparable, Cell) - Method in class org.apache.hadoop.hbase.filter.CompareFilter
 
compareFamily(CompareFilter.CompareOp, ByteArrayComparable, Cell) - Method in class org.apache.hadoop.hbase.filter.CompareFilter
Deprecated.
Since 2.0.0. Will be removed in 3.0.0. Use CompareFilter.compareFamily(CompareOperator, ByteArrayComparable, Cell)
org.apache.hadoop.hbase.filter.CompareFilter - Class in org.apache.hadoop.hbase.filter
This is a generic filter to be used to filter by comparison.
CompareFilter(CompareOperator, ByteArrayComparable) - Constructor for class org.apache.hadoop.hbase.filter.CompareFilter
Constructor.
CompareFilter(CompareFilter.CompareOp, ByteArrayComparable) - Constructor for class org.apache.hadoop.hbase.filter.CompareFilter
Deprecated.
Since 2.0.0. Will be removed in 3.0.0. Use other constructor.
org.apache.hadoop.hbase.filter.CompareFilter.CompareOp - Enum in org.apache.hadoop.hbase.filter
Deprecated.
since 2.0.0. Will be removed in 3.0.0. Use CompareOperator instead.
compareFlatKey(byte[], byte[]) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
Deprecated.
 
compareFlatKey(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
Deprecated.
Compares left to right assuming that left,loffset,llength and right,roffset,rlength are full KVs laid out in a flat byte[]s.
compareIgnoringPrefix(int, byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
Deprecated.
Overridden
compareIgnoringPrefix(int, byte[], int, int, byte[], int, int) - Method in interface org.apache.hadoop.hbase.KeyValue.SamePrefixComparator
Compare two keys assuming that the first n bytes are the same.
compareKey(CellComparator, Cell) - Method in interface org.apache.hadoop.hbase.io.encoding.DataBlockEncoder.EncodedSeeker
Compare the given key against the current key
compareKey(CellComparator, Cell) - Method in class org.apache.hadoop.hbase.io.encoding.RowIndexSeekerV1
 
compareKey(CellComparator, Cell) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.EncodedScanner
 
compareKey(CellComparator, Cell) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
 
compareKey(Cell, byte[], int, int, byte[], int, int, byte[], int, int, long, byte) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
Deprecated.
 
compareKey(TNode, Object) - Method in interface org.apache.hadoop.hbase.util.AvlUtil.AvlKeyComparator
 
compareKeyBasedOnColHint(CellComparator, Cell, Cell, int, int, byte[], int, int, long, byte) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
Used to compare two cells based on the column hint provided.
compareKeyForNextColumn(Cell, Cell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher
 
compareKeyForNextRow(Cell, Cell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher
 
compareKeyIgnoresMvcc(CellComparator, Cell, Cell) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
Compares only the key portion of a cell.
compareOnlyKeyPortion(Cell, Cell) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
Deprecated.
 
compareOnlyKeyPortion(Cell, Cell) - Method in class org.apache.hadoop.hbase.KeyValue.MetaComparator
Deprecated.
 
org.apache.hadoop.hbase.CompareOperator - Enum in org.apache.hadoop.hbase
Generic set of comparison operators.
compareQualifier(Cell, ByteArrayComparable) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
Compare cell's qualifier against given comparator
compareQualifier(CompareOperator, ByteArrayComparable, Cell) - Method in class org.apache.hadoop.hbase.filter.CompareFilter
 
compareQualifier(CompareFilter.CompareOp, ByteArrayComparable, Cell) - Method in class org.apache.hadoop.hbase.filter.CompareFilter
Deprecated.
Since 2.0.0. Will be removed in 3.0.0. Use CompareFilter.compareQualifier(CompareOperator, ByteArrayComparable, Cell)
compareQualifiers(Cell, byte[], int, int) - Static method in class org.apache.hadoop.hbase.CellUtil
Compares the cell's qualifier with the given byte[]
compareQualifiers(Cell, Cell) - Method in interface org.apache.hadoop.hbase.CellComparator
Lexicographically compares the qualifiers of the two cells
compareQualifiers(Cell, Cell) - Method in class org.apache.hadoop.hbase.CellComparatorImpl
Compare the qualifiers part of the left and right cells.
compareResults(Result, Result) - Static method in class org.apache.hadoop.hbase.client.Result
Does a deep comparison of two Results, down to the byte arrays.
compareResults(Result, Result, boolean) - Static method in class org.apache.hadoop.hbase.client.Result
Does a deep comparison of two Results, down to the byte arrays.
compareRow(Cell, ByteArrayComparable) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
Compare cell's row against given comparator
compareRow(CompareOperator, ByteArrayComparable, Cell) - Method in class org.apache.hadoop.hbase.filter.CompareFilter
 
compareRow(CompareFilter.CompareOp, ByteArrayComparable, Cell) - Method in class org.apache.hadoop.hbase.filter.CompareFilter
Deprecated.
Since 2.0.0. Will be removed in 3.0.0. Use CompareFilter.compareRow(CompareOperator, ByteArrayComparable, Cell)
compareRowKey(Cell, Cell) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
Deprecated.
Compares the only the user specified portion of a Key.
compareRowKey(Cell, Cell) - Method in class org.apache.hadoop.hbase.KeyValue.MetaComparator
Deprecated.
Override the row key comparison to parse and compare the meta row key parts.
compareRows(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.CellComparator
Compares two row bytes
compareRows(byte[], byte[]) - Method in class org.apache.hadoop.hbase.MetaCellComparator
 
compareRows(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
Deprecated.
Get the b[],o,l for left and right rowkey portions and compare.
compareRows(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.KeyValue.MetaComparator
Deprecated.
 
compareRows(ByteBuffer, Cell) - Method in interface org.apache.hadoop.hbase.CellComparator
Lexicographically compare two rows
compareRows(ByteBuffer, Cell) - Method in class org.apache.hadoop.hbase.MetaCellComparator
 
compareRows(Cell, byte[], int, int) - Method in interface org.apache.hadoop.hbase.CellComparator
Compares the row part of the cell with a simple plain byte[] like the stopRow in Scan.
compareRows(Cell, byte[], int, int) - Method in class org.apache.hadoop.hbase.CellComparatorImpl
Compares the row part of the cell with a simple plain byte[] like the stopRow in Scan.
compareRows(Cell, byte[], int, int) - Method in class org.apache.hadoop.hbase.MetaCellComparator
 
compareRows(Cell, Cell) - Method in interface org.apache.hadoop.hbase.CellComparator
Lexographically compares the rows of two cells.
compareRows(Cell, Cell) - Method in class org.apache.hadoop.hbase.CellComparatorImpl
Compares the rows of the left and right cell.
compareRows(Cell, Cell) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
Deprecated.
Compares the rows of a cell
compareRows(Cell, Cell) - Method in class org.apache.hadoop.hbase.MetaCellComparator
 
compareRows(Cell, Cell) - Method in class org.apache.hadoop.hbase.regionserver.CompositeImmutableSegment
 
compareRows(Cell, Cell) - Method in class org.apache.hadoop.hbase.regionserver.Segment
 
compareTimestamps(long, long) - Method in interface org.apache.hadoop.hbase.CellComparator
Compares cell's timestamps in DESCENDING order.
compareTimestamps(long, long) - Method in class org.apache.hadoop.hbase.CellComparatorImpl
 
compareTimestamps(Cell, Cell) - Method in interface org.apache.hadoop.hbase.CellComparator
Compares cell's timestamps in DESCENDING order.
compareTimestamps(Cell, Cell) - Method in class org.apache.hadoop.hbase.CellComparatorImpl
 
compareTimestamps(Cell, Cell) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
Deprecated.
 
compareTo(byte[]) - Method in class org.apache.hadoop.hbase.filter.BinaryComponentComparator
 
compareTo(byte[]) - Method in class org.apache.hadoop.hbase.filter.ByteArrayComparable
 
compareTo(byte[]) - Method in class org.apache.hadoop.hbase.filter.NullComparator
 
compareTo(byte[]) - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
Compares the bytes in this object to the specified byte array
compareTo(byte[]) - Method in class org.apache.hadoop.hbase.util.Bytes
Compares the bytes in this object to the specified byte array
compareTo(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
Lexicographically compare two arrays.
compareTo(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.BigDecimalComparator
 
compareTo(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.BinaryComparator
 
compareTo(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.BinaryComponentComparator
 
compareTo(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.BinaryPrefixComparator
 
compareTo(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.BitComparator
 
compareTo(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.ByteArrayComparable
Special compareTo method for subclasses, to avoid copying byte[] unnecessarily.
compareTo(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.LongComparator
 
compareTo(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.NullComparator
 
compareTo(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.RegexStringComparator
 
compareTo(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.SubstringComparator
 
compareTo(byte[], int, int, byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Lexicographically compare two arrays.
compareTo(byte[], int, int, ByteBuffer, int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
Deprecated.
 
compareTo(ByteBuffer, int, int) - Method in class org.apache.hadoop.hbase.filter.BigDecimalComparator
 
compareTo(ByteBuffer, int, int) - Method in class org.apache.hadoop.hbase.filter.BinaryComparator
 
compareTo(ByteBuffer, int, int) - Method in class org.apache.hadoop.hbase.filter.BinaryPrefixComparator
 
compareTo(ByteBuffer, int, int) - Method in class org.apache.hadoop.hbase.filter.BitComparator
 
compareTo(ByteBuffer, int, int) - Method in class org.apache.hadoop.hbase.filter.ByteArrayComparable
Special compareTo method for subclasses, to avoid copying bytes unnecessarily.
compareTo(ByteBuffer, int, int) - Method in class org.apache.hadoop.hbase.filter.LongComparator
 
compareTo(ByteBuffer, int, int) - Method in class org.apache.hadoop.hbase.filter.NullComparator
 
compareTo(ByteBuffer, int, int, byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
Deprecated.
 
compareTo(ByteBuffer, int, int, ByteBuffer, int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
Deprecated.
 
compareTo(Delayed) - Method in class org.apache.hadoop.hbase.JitterScheduledThreadPoolExecutorImpl.JitteredRunnableScheduledFuture
 
compareTo(BackupInfo) - Method in class org.apache.hadoop.hbase.backup.BackupInfo
We use only time stamps to compare objects during sort operation
compareTo(Action) - Method in class org.apache.hadoop.hbase.client.Action
 
compareTo(ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
 
compareTo(RegionInfo) - Method in interface org.apache.hadoop.hbase.client.RegionInfo
 
compareTo(Row) - Method in class org.apache.hadoop.hbase.client.CheckAndMutate
 
compareTo(Row) - Method in class org.apache.hadoop.hbase.client.Get
 
compareTo(Row) - Method in class org.apache.hadoop.hbase.client.Mutation
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use Row.COMPARATOR instead
compareTo(Row) - Method in class org.apache.hadoop.hbase.client.RegionCoprocessorServiceExec
 
compareTo(Row) - Method in interface org.apache.hadoop.hbase.client.Row
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use Row.COMPARATOR instead
compareTo(Row) - Method in class org.apache.hadoop.hbase.client.RowMutations
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use Row.COMPARATOR instead
compareTo(TableDescriptorBuilder.ModifyableTableDescriptor) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
Compares the descriptor with another descriptor which is passed as a parameter.
compareTo(MultiRowRangeFilter.BasicRowRange) - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.RowRange
 
compareTo(FieldValue) - Method in class org.apache.hadoop.hbase.hbtop.field.FieldValue
 
compareTo(HColumnDescriptor) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
compareTo(HRegionLocation) - Method in class org.apache.hadoop.hbase.HRegionLocation
 
compareTo(HTableDescriptor) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
Compares the descriptor with another descriptor which is passed as a parameter.
compareTo(LruCachedBlock) - Method in class org.apache.hadoop.hbase.io.hfile.LruCachedBlock
 
compareTo(ImmutableBytesWritable) - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
Define the sort order of the BytesWritable.
compareTo(TableSplit) - Method in class org.apache.hadoop.hbase.mapred.TableSplit
 
compareTo(Import.CellWritableComparable) - Method in class org.apache.hadoop.hbase.mapreduce.Import.CellWritableComparable
 
compareTo(Import.KeyValueWritableComparable) - Method in class org.apache.hadoop.hbase.mapreduce.Import.KeyValueWritableComparable
 
compareTo(TableSplit) - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
Compares this split against the given one.
compareTo(RegionPlan) - Method in class org.apache.hadoop.hbase.master.RegionPlan
Compare the region info.
compareTo(CachedMobFile) - Method in class org.apache.hadoop.hbase.mob.CachedMobFile
 
compareTo(Address) - Method in class org.apache.hadoop.hbase.net.Address
 
compareTo(ByteBuff, int, int, ByteBuff, int, int) - Static method in class org.apache.hadoop.hbase.nio.ByteBuff
Compares two ByteBuffs
compareTo(MetricsRegionSource) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionSourceImpl
 
compareTo(MetricsTableSource) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableSourceImpl
 
compareTo(MetricsUserSource) - Method in class org.apache.hadoop.hbase.regionserver.MetricsUserSourceImpl
 
compareTo(ServerName) - Method in class org.apache.hadoop.hbase.ServerName
 
compareTo(Size) - Method in class org.apache.hadoop.hbase.Size
 
compareTo(TableName) - Method in class org.apache.hadoop.hbase.TableName
 
compareTo(ByteRange) - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
Bitwise comparison of each byte in the array.
compareTo(Bytes) - Method in class org.apache.hadoop.hbase.util.Bytes
Define the sort order of the Bytes.
compareTo(WALKey) - Method in class org.apache.hadoop.hbase.wal.WALKeyImpl
 
compareTo(WALSplitUtil.MutationReplay) - Method in class org.apache.hadoop.hbase.wal.WALSplitUtil.MutationReplay
 
compareTo(TNode) - Method in class org.apache.hadoop.hbase.util.AvlUtil.AvlNode
 
compareToIgnoreCase(FieldValue) - Method in class org.apache.hadoop.hbase.hbtop.field.FieldValue
 
compareValue(Cell, ByteArrayComparable) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
Compare cell's value against given comparator
compareValue(CompareOperator, ByteArrayComparable, Cell) - Method in class org.apache.hadoop.hbase.filter.CompareFilter
 
compareValue(CompareFilter.CompareOp, ByteArrayComparable, Cell) - Method in class org.apache.hadoop.hbase.filter.CompareFilter
Deprecated.
Since 2.0.0. Will be removed in 3.0.0. Use CompareFilter.compareValue(CompareOperator, ByteArrayComparable, Cell)
compareVersion(String, String) - Static method in class org.apache.hadoop.hbase.util.VersionInfo
 
compareWithoutRow(Cell, Cell) - Method in interface org.apache.hadoop.hbase.CellComparator
Lexicographically compares the two cells excluding the row part.
compareWithoutRow(Cell, Cell) - Method in class org.apache.hadoop.hbase.CellComparatorImpl
 
org.apache.hadoop.hbase.CompatibilityFactory - Class in org.apache.hadoop.hbase
Class that will create many instances of classes provided by the hbase-hadoop{1|2}-compat jars.
CompatibilityFactory() - Constructor for class org.apache.hadoop.hbase.CompatibilityFactory
This is a static only class don't let any instance be created.
org.apache.hadoop.hbase.CompatibilitySingletonFactory - Class in org.apache.hadoop.hbase
Factory for classes supplied by hadoop compatibility modules.
CompatibilitySingletonFactory() - Constructor for class org.apache.hadoop.hbase.CompatibilitySingletonFactory
This is a static only class don't let anyone create an instance.
org.apache.hadoop.hbase.CompatibilitySingletonFactory.SingletonStorage - Enum in org.apache.hadoop.hbase
 
complete() - Method in class org.apache.hadoop.hbase.errorhandling.TimeoutExceptionInjector
For all time forward, do not throw an error because the process has completed.
complete(Path) - Static method in class org.apache.hadoop.hbase.io.hfile.PrefetchExecutor
 
complete(MultiVersionConcurrencyControl.WriteEntry) - Method in class org.apache.hadoop.hbase.regionserver.MultiVersionConcurrencyControl
Mark the MultiVersionConcurrencyControl.WriteEntry as complete and advance the read point as much as possible.
COMPLETE - Enum constant in enum org.apache.hadoop.hbase.backup.BackupInfo.BackupState
 
COMPLETE - Enum constant in enum org.apache.hadoop.hbase.ServerTask.State
 
completeAndWait(MultiVersionConcurrencyControl.WriteEntry) - Method in class org.apache.hadoop.hbase.regionserver.MultiVersionConcurrencyControl
Complete a MultiVersionConcurrencyControl.WriteEntry that was created by MultiVersionConcurrencyControl.begin() then wait until the read point catches up to our write.
completeCacheFlush(byte[], long) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
 
completeCacheFlush(byte[], long) - Method in interface org.apache.hadoop.hbase.wal.WAL
Complete the cache flush.
completed(Store) - Method in interface org.apache.hadoop.hbase.regionserver.CompactSplit.CompactionCompleteTracker
 
CompletedSnaphotDirectoriesFilter(FileSystem) - Constructor for class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils.CompletedSnaphotDirectoriesFilter
 
completeExceptionally() - Method in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCaller
 
completeSnapshot(Path, Path, FileSystem, FileSystem, Configuration) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
Commits the snapshot process by moving the working snapshot to the finalized filepath
components - Variable in class org.apache.hadoop.hbase.util.ConcatenatedLists
 
org.apache.hadoop.hbase.regionserver.CompositeImmutableSegment - Class in org.apache.hadoop.hbase.regionserver
The CompositeImmutableSegments is created as a collection of ImmutableSegments and supports the interface of a single ImmutableSegments.
CompositeImmutableSegment(CellComparator, List<ImmutableSegment>) - Constructor for class org.apache.hadoop.hbase.regionserver.CompositeImmutableSegment
 
org.apache.hadoop.hbase.io.hfile.CompoundBloomFilter - Class in org.apache.hadoop.hbase.io.hfile
A Bloom filter implementation built on top of BloomFilterChunk, encapsulating a set of fixed-size Bloom filters written out at the time of HFile generation into the data block stream, and loaded on demand at query time.
CompoundBloomFilter(DataInput, HFile.Reader, BloomFilterMetrics) - Constructor for class org.apache.hadoop.hbase.io.hfile.CompoundBloomFilter
De-serialization for compound Bloom filter metadata.
org.apache.hadoop.hbase.io.hfile.CompoundBloomFilterBase - Class in org.apache.hadoop.hbase.io.hfile
 
CompoundBloomFilterBase() - Constructor for class org.apache.hadoop.hbase.io.hfile.CompoundBloomFilterBase
 
org.apache.hadoop.hbase.io.hfile.CompoundBloomFilterWriter - Class in org.apache.hadoop.hbase.io.hfile
Adds methods required for writing a compound Bloom filter to the data section of an HFile to the CompoundBloomFilter class.
CompoundBloomFilterWriter(int, float, int, int, boolean, CellComparator, BloomType) - Constructor for class org.apache.hadoop.hbase.io.hfile.CompoundBloomFilterWriter
each chunk's size in bytes.
org.apache.hadoop.hbase.CompoundConfiguration - Class in org.apache.hadoop.hbase
Do a shallow merge of multiple KV configuration pools.
CompoundConfiguration() - Constructor for class org.apache.hadoop.hbase.CompoundConfiguration
Default Constructor.
compress(byte[], Enum) - Method in interface org.apache.hadoop.hbase.regionserver.wal.WALCellCodec.ByteStringCompressor
 
COMPRESS_TAGS - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
COMPRESS_TAGS - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
compressAndEncrypt(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultEncodingContext
 
compressAndEncrypt(byte[], int, int) - Method in interface org.apache.hadoop.hbase.io.encoding.HFileBlockEncodingContext
Compress and encrypt the supplied encoded block data with header.
compressFamily(OutputStream, Cell, Dictionary) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
 
compression - Variable in class org.apache.hadoop.hbase.regionserver.wal.WALCellCodec
 
compression() - Method in class org.apache.hadoop.hbase.regionserver.CreateStoreFileWriterParams
 
compression(Compression.Algorithm) - Method in class org.apache.hadoop.hbase.regionserver.CreateStoreFileWriterParams
Set the compression algorithm to use
org.apache.hadoop.hbase.io.compress.Compression - Class in org.apache.hadoop.hbase.io.compress
Compression related stuff.
COMPRESSION - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
COMPRESSION - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
COMPRESSION_COMPACT - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
COMPRESSION_COMPACT - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
COMPRESSION_COMPACT_MAJOR - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
COMPRESSION_COMPACT_MAJOR - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
COMPRESSION_COMPACT_MINOR - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
COMPRESSION_COMPACT_MINOR - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
COMPRESSION_OVERRIDE_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
 
org.apache.hadoop.hbase.io.compress.Compression.Algorithm - Enum in org.apache.hadoop.hbase.io.compress
Compression algorithms.
compressionByName(String) - Static method in class org.apache.hadoop.hbase.io.hfile.HFileWriterImpl
 
compressionContext - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractProtobufLogWriter
 
org.apache.hadoop.hbase.regionserver.wal.CompressionContext - Class in org.apache.hadoop.hbase.regionserver.wal
Context that holds the various dictionaries for compression in WAL.
CompressionContext(Class<? extends Dictionary>, boolean, boolean) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.CompressionContext
 
CompressionContext(Class<? extends Dictionary>, boolean, boolean, boolean, Compression.Algorithm) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.CompressionContext
 
org.apache.hadoop.hbase.regionserver.wal.CompressionContext.DictionaryIndex - Enum in org.apache.hadoop.hbase.regionserver.wal
 
compressionCtx - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractProtobufWALReader
 
compressionOverhead(int) - Static method in class org.apache.hadoop.hbase.io.compress.CompressionUtil
Most compression algorithms can be presented with pathological input that causes an expansion rather than a compression.
org.apache.hadoop.hbase.util.CompressionTest - Class in org.apache.hadoop.hbase.util
Compression validation test.
CompressionTest() - Constructor for class org.apache.hadoop.hbase.util.CompressionTest
 
org.apache.hadoop.hbase.io.compress.CompressionUtil - Class in org.apache.hadoop.hbase.io.compress
 
compressor - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
compressor - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractProtobufLogWriter
 
org.apache.hadoop.hbase.regionserver.wal.Compressor - Class in org.apache.hadoop.hbase.regionserver.wal
A set of static functions for running our custom WAL compression/decompression.
Compressor() - Constructor for class org.apache.hadoop.hbase.regionserver.wal.Compressor
 
compressQualifier(OutputStream, Cell, Dictionary) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
 
compressRow(OutputStream, Cell, Dictionary) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
 
compressTags(OutputStream, byte[], int, int) - Method in class org.apache.hadoop.hbase.io.TagCompressionContext
Compress tags one by one and writes to the OutputStream.
compressTags(OutputStream, ByteBuffer, int, int) - Method in class org.apache.hadoop.hbase.io.TagCompressionContext
Compress tags one by one and writes to the OutputStream.
compressTags(OutputStream, Cell, TagCompressionContext) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
Compresses the tags to the given outputstream using the TagcompressionContext
computeAndStoreSnapshotSizes(Collection<String>) - Method in interface org.apache.hadoop.hbase.quotas.FileArchiverNotifier
Computes the size of a table and all of its snapshots, recording new "full" sizes for each.
computeAndStoreSnapshotSizes(Collection<String>) - Method in class org.apache.hadoop.hbase.quotas.FileArchiverNotifierImpl
 
computeBitSize(long, double) - Static method in class org.apache.hadoop.hbase.util.BloomFilterUtil
 
computeBulkLoadSize(FileSystem, List<String>) - Method in class org.apache.hadoop.hbase.quotas.policies.DefaultViolationPolicyEnforcement
 
computeBulkLoadSize(FileSystem, List<String>) - Method in class org.apache.hadoop.hbase.quotas.policies.MissingSnapshotViolationPolicyEnforcement
 
computeBulkLoadSize(FileSystem, List<String>) - Method in interface org.apache.hadoop.hbase.quotas.SpaceViolationPolicyEnforcement
Computes the size of the file(s) at the given path against this policy and the current SpaceQuotaSnapshot.
computeCryptoKeyHash(Configuration, byte[]) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
Returns the hash of the supplied argument, using the hash algorithm specified in the given config.
computeDelta(TableDescriptor, TableDescriptor) - Static method in class org.apache.hadoop.hbase.client.TableDescriptorUtils
Compares two TableDescriptor and indicate which columns were added, deleted, or modified from oldTD to newTD
computeFilename(long) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
This is a convenience method that computes a new filename with a given file-number.
computeFoldableByteSize(long, int) - Static method in class org.apache.hadoop.hbase.util.BloomFilterUtil
Increases the given byte size of a Bloom filter until it can be folded by the given factor.
computeHDFSBlocksDistribution(Configuration, TableDescriptor, RegionInfo) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
This is a helper function to compute HDFS block distribution on demand
computeHDFSBlocksDistribution(Configuration, TableDescriptor, RegionInfo, Path) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
This is a helper function to compute HDFS block distribution on demand
computeHDFSBlocksDistribution(FileSystem) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
Compute the HDFS Block Distribution for this StoreFile
computeHDFSBlocksDistribution(FileSystem, FileStatus, long, long) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Compute HDFS blocks distribution of a given file, or a portion of the file
computeHDFSBlocksDistribution(HdfsDataInputStream) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Compute HDFS block distribution of a given HdfsDataInputStream.
computeIfAbsent(ConcurrentMap<K, V>, K, Supplier<V>) - Static method in class org.apache.hadoop.hbase.util.ConcurrentMapUtils
In HBASE-16648 we found that ConcurrentHashMap.get is much faster than computeIfAbsent if the value already exists.
computeIfAbsent(ConcurrentMap<K, V>, K, Supplier<V>, Runnable) - Static method in class org.apache.hadoop.hbase.util.ConcurrentMapUtils
 
computeIfAbsentEx(ConcurrentMap<K, V>, K, IOExceptionSupplier<V>) - Static method in class org.apache.hadoop.hbase.util.ConcurrentMapUtils
In HBASE-16648 we found that ConcurrentHashMap.get is much faster than computeIfAbsent if the value already exists.
computeMaxKeys(long, double, int) - Static method in class org.apache.hadoop.hbase.util.BloomFilterUtil
The maximum number of keys we can put into a Bloom filter of a certain size to get the given error rate, with the given number of hash functions.
computeNumCallQueues(int, float) - Method in class org.apache.hadoop.hbase.ipc.RpcExecutor
 
computeNumCallQueues(int, float) - Method in class org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
 
org.apache.hadoop.hbase.util.ConcatenatedLists<T> - Class in org.apache.hadoop.hbase.util
A collection class that contains multiple sub-lists, which allows us to not copy lists.
ConcatenatedLists() - Constructor for class org.apache.hadoop.hbase.util.ConcatenatedLists
 
org.apache.hadoop.hbase.util.ConcatenatedLists.Iterator - Class in org.apache.hadoop.hbase.util
 
concatTags(byte[], Cell) - Static method in class org.apache.hadoop.hbase.TagUtil
 
CONCURRENT_HASHMAP - Static variable in class org.apache.hadoop.hbase.util.ClassSize
Overhead for ConcurrentHashMap
CONCURRENT_HASHMAP_ENTRY - Static variable in class org.apache.hadoop.hbase.util.ClassSize
Overhead for ConcurrentHashMap.Entry
CONCURRENT_HASHMAP_SEGMENT - Static variable in class org.apache.hadoop.hbase.util.ClassSize
Overhead for ConcurrentHashMap.Segment
CONCURRENT_SKIPLISTMAP - Static variable in class org.apache.hadoop.hbase.util.ClassSize
Overhead for ConcurrentSkipListMap
CONCURRENT_SKIPLISTMAP_ENTRY - Static variable in class org.apache.hadoop.hbase.util.ClassSize
Overhead for ConcurrentSkipListMap Entry
org.apache.hadoop.hbase.util.ConcurrentMapUtils - Class in org.apache.hadoop.hbase.util
Utility methods for dealing with Collections, including treating null collections as empty.
ConcurrentMapUtils() - Constructor for class org.apache.hadoop.hbase.util.ConcurrentMapUtils
 
org.apache.hadoop.hbase.ConcurrentTableModificationException - Exception in org.apache.hadoop.hbase
Thrown when a table has been modified concurrently
ConcurrentTableModificationException() - Constructor for exception org.apache.hadoop.hbase.ConcurrentTableModificationException
default constructor
ConcurrentTableModificationException(byte[]) - Constructor for exception org.apache.hadoop.hbase.ConcurrentTableModificationException
 
ConcurrentTableModificationException(String) - Constructor for exception org.apache.hadoop.hbase.ConcurrentTableModificationException
Constructor
ConcurrentTableModificationException(TableName) - Constructor for exception org.apache.hadoop.hbase.ConcurrentTableModificationException
 
concurrentVisitReferencedFiles(Configuration, FileSystem, SnapshotManifest, String, SnapshotReferenceUtil.StoreFileVisitor) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotReferenceUtil
 
concurrentVisitReferencedFiles(Configuration, FileSystem, SnapshotManifest, ExecutorService, SnapshotReferenceUtil.StoreFileVisitor) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotReferenceUtil
 
conf - Variable in class org.apache.hadoop.hbase.client.ClientScanner
 
conf - Variable in class org.apache.hadoop.hbase.client.RpcRetryingCallerWithReadReplicas
 
conf - Variable in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
 
conf - Variable in class org.apache.hadoop.hbase.io.hfile.HFile.WriterFactory
 
conf - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
conf - Variable in class org.apache.hadoop.hbase.ipc.PluggableBlockingQueue
 
conf - Variable in class org.apache.hadoop.hbase.ipc.RpcControllerFactory
 
conf - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
 
conf - Variable in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
 
conf - Variable in class org.apache.hadoop.hbase.regionserver.HRegion
 
conf - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
conf - Variable in class org.apache.hadoop.hbase.regionserver.HStore
 
conf - Variable in class org.apache.hadoop.hbase.regionserver.StoreFileReader
 
conf - Variable in class org.apache.hadoop.hbase.regionserver.DefaultStoreFlusher
 
conf - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
conf object
conf - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractProtobufLogWriter
 
conf - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractProtobufWALReader
 
conf - Variable in class org.apache.hadoop.hbase.replication.ZKReplicationStorageBase
 
conf - Static variable in class org.apache.hadoop.hbase.rest.RESTServer
 
conf - Variable in class org.apache.hadoop.hbase.thrift.HBaseServiceHandler
 
conf - Variable in class org.apache.hadoop.hbase.thrift.ThriftServer
 
conf - Variable in class org.apache.hadoop.hbase.util.AbstractHBaseTool
 
conf - Variable in class org.apache.hadoop.hbase.wal.AbstractFSWALProvider
 
conf - Variable in class org.apache.hadoop.hbase.wal.WALSplitter
 
conf() - Method in class org.apache.hadoop.hbase.testing.TestingHBaseClusterOption
 
conf(Configuration) - Method in class org.apache.hadoop.hbase.testing.TestingHBaseClusterOption.Builder
 
CONF_CONTEXT_ATTRIBUTE - Static variable in class org.apache.hadoop.hbase.http.HttpServer
 
CONF_DEST_PREFIX - Static variable in class org.apache.hadoop.hbase.snapshot.ExportSnapshot
Configuration prefix for overrides for the destination filesystem
CONF_SKIP_TMP - Static variable in class org.apache.hadoop.hbase.snapshot.ExportSnapshot
 
CONF_SOURCE_PREFIX - Static variable in class org.apache.hadoop.hbase.snapshot.ExportSnapshot
Configuration prefix for overrides for the source filesystem
CONF_STAGING_ROOT - Static variable in interface org.apache.hadoop.hbase.backup.BackupRestoreConstants
 
CONFIG - Static variable in class org.apache.hadoop.hbase.HBaseInterfaceAudience
Denotes class names that appear in user facing configuration files.
CONFIGURATION - Static variable in class org.apache.hadoop.hbase.HConstants
 
configurationManager - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
Configuration manager is used to register/deregister and notify the configuration observers when the regionserver is notified that there was a change in the on disk configs.
org.apache.hadoop.hbase.conf.ConfigurationManager - Class in org.apache.hadoop.hbase.conf
Maintains the set of all the classes which would like to get notified when the Configuration is reloaded from the disk in the Online Configuration Change mechanism, which lets you update certain configuration properties on-the-fly, without having to restart the cluster.
ConfigurationManager() - Constructor for class org.apache.hadoop.hbase.conf.ConfigurationManager
 
org.apache.hadoop.hbase.conf.ConfigurationObserver - Interface in org.apache.hadoop.hbase.conf
Every class that wants to observe changes in Configuration properties, must implement interface (and also, register itself with the ConfigurationManager.
org.apache.hadoop.hbase.util.ConfigurationUtil - Class in org.apache.hadoop.hbase.util
Utilities for storing more complex collection types in Configuration instances.
configure(JobConf) - Method in class org.apache.hadoop.hbase.mapred.GroupingTableMap
 
configure(JobConf) - Method in class org.apache.hadoop.hbase.mapred.HRegionPartitioner
 
configure(JobConf) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormat
 
configureCfRenaming(Configuration, Map<String, String>) - Static method in class org.apache.hadoop.hbase.mapreduce.Import
Sets a configuration property with key Import.CF_RENAME_PROP in conf that tells the mapper how to rename column families.
configureForRegion(HRegion) - Method in class org.apache.hadoop.hbase.regionserver.BusyRegionSplitPolicy
 
configureForRegion(HRegion) - Method in class org.apache.hadoop.hbase.regionserver.ConstantSizeRegionSplitPolicy
 
configureForRegion(HRegion) - Method in class org.apache.hadoop.hbase.regionserver.DelimitedKeyPrefixRegionSplitPolicy
Deprecated.
 
configureForRegion(HRegion) - Method in class org.apache.hadoop.hbase.regionserver.FlushAllLargeStoresPolicy
 
configureForRegion(HRegion) - Method in class org.apache.hadoop.hbase.regionserver.FlushNonSloppyStoresFirstPolicy
 
configureForRegion(HRegion) - Method in class org.apache.hadoop.hbase.regionserver.FlushPolicy
Upon construction, this method will be called with the region to be governed.
configureForRegion(HRegion) - Method in class org.apache.hadoop.hbase.regionserver.IncreasingToUpperBoundRegionSplitPolicy
 
configureForRegion(HRegion) - Method in class org.apache.hadoop.hbase.regionserver.KeyPrefixRegionSplitPolicy
Deprecated.
 
configureForRegion(HRegion) - Method in class org.apache.hadoop.hbase.regionserver.RegionSplitPolicy
Upon construction, this method will be called with the region to be governed.
configureIncrementalLoad(Job, List<HFileOutputFormat2.TableInfo>) - Static method in class org.apache.hadoop.hbase.mapreduce.MultiTableHFileOutputFormat
Analogous to HFileOutputFormat2.configureIncrementalLoad(Job, TableDescriptor, RegionLocator), this function will configure the requisite number of reducers to write HFiles for multple tables simultaneously
configureIncrementalLoad(Job, TableDescriptor, RegionLocator) - Static method in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
Configure a MapReduce Job to perform an incremental load into the given table.
configureIncrementalLoad(Job, Table, RegionLocator) - Static method in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
Configure a MapReduce Job to perform an incremental load into the given table.
configureIncrementalLoadMap(Job, TableDescriptor) - Static method in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
 
configureInfoServer() - Method in class org.apache.hadoop.hbase.master.HMaster
 
configureInfoServer() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
configureJob(Configuration, String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.IndexBuilder
Job configuration.
configureJob(Configuration, String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.SampleUploader
Job configuration.
configureRemoteCluster(Job, Configuration) - Static method in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
Configure HBase cluster key for remote cluster to load region location for locality-sensitive if it's enabled.
configureRpcController(RpcController) - Method in class org.apache.hadoop.hbase.ipc.AbstractRpcClient.RpcChannelImplementation
Configure an rpc controller
configureSplitTable(Job, TableName) - Static method in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
Sets split table in map-reduce job.
org.apache.hadoop.hbase.http.conf.ConfServlet - Class in org.apache.hadoop.hbase.http.conf
A servlet to print out the running configuration data.
ConfServlet() - Constructor for class org.apache.hadoop.hbase.http.conf.ConfServlet
 
org.apache.hadoop.hbase.http.conf.ConfServlet.BadFormatException - Exception in org.apache.hadoop.hbase.http.conf
 
conn - Variable in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCaller
 
connect() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
Deprecated.
To repair region consistency, one must call connect() in order to repair online state.
connect(Configuration) - Method in class org.apache.hadoop.hbase.master.ClusterStatusPublisher.MulticastPublisher
 
connect(Configuration) - Method in interface org.apache.hadoop.hbase.master.ClusterStatusPublisher.Publisher
 
connect(Configuration, String, Watcher, String, ZKClientConfig) - Static method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
Creates a new connection to ZooKeeper, pulling settings and ensemble config from the specified configuration object using methods from ZKConfig.
connect(Configuration, Watcher) - Static method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
See RecoverableZooKeeper.connect(Configuration, String, Watcher, String, ZKClientConfig).
connection - Variable in class org.apache.hadoop.hbase.client.RegionAdminServiceCallable
 
connection - Variable in class org.apache.hadoop.hbase.ipc.ServerCall
 
connection - Variable in class org.apache.hadoop.hbase.util.compaction.MajorCompactionTTLRequest
 
connection - Variable in class org.apache.hadoop.hbase.util.compaction.MajorCompactor
 
org.apache.hadoop.hbase.client.Connection - Interface in org.apache.hadoop.hbase.client
A cluster connection encapsulating lower level individual connections to actual servers and a connection to zookeeper.
connectionAttributes - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
connectionCache - Variable in class org.apache.hadoop.hbase.thrift.HBaseServiceHandler
 
org.apache.hadoop.hbase.util.ConnectionCache - Class in org.apache.hadoop.hbase.util
A utility to store user specific HConnections in memory.
ConnectionCache(Configuration, UserProvider, int, int) - Constructor for class org.apache.hadoop.hbase.util.ConnectionCache
 
org.apache.hadoop.hbase.exceptions.ConnectionClosedException - Exception in org.apache.hadoop.hbase.exceptions
Thrown when the connection is closed
ConnectionClosedException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.ConnectionClosedException
 
ConnectionClosedException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.exceptions.ConnectionClosedException
ConnectionClosedException with cause
org.apache.hadoop.hbase.exceptions.ConnectionClosingException - Exception in org.apache.hadoop.hbase.exceptions
Thrown when the client believes that we are trying to communicate to has been repeatedly unresponsive for a while.
ConnectionClosingException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.ConnectionClosingException
 
ConnectionClosingException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.exceptions.ConnectionClosingException
ConnectionClosingException with cause
org.apache.hadoop.hbase.client.ConnectionConfiguration - Class in org.apache.hadoop.hbase.client
Configuration parameters for the connection.
ConnectionConfiguration() - Constructor for class org.apache.hadoop.hbase.client.ConnectionConfiguration
Constructor This is for internal testing purpose (using the default value).
org.apache.hadoop.hbase.client.ConnectionFactory - Class in org.apache.hadoop.hbase.client
A non-instantiable class that manages creation of Connections.
ConnectionFactory() - Constructor for class org.apache.hadoop.hbase.client.ConnectionFactory
No public c.tors
org.apache.hadoop.hbase.client.ConnectionImplementation - Class in org.apache.hadoop.hbase.client
Main implementation of Connection and ClusterConnection interfaces.
org.apache.hadoop.hbase.client.ConnectionRegistry - Interface in org.apache.hadoop.hbase.client
Registry for meta information needed for connection setup to a HBase cluster.
org.apache.hadoop.hbase.client.trace.ConnectionSpanBuilder - Class in org.apache.hadoop.hbase.client.trace
Construct Span instances originating from the client side of a connection.
ConnectionSpanBuilder(AsyncConnectionImpl) - Constructor for class org.apache.hadoop.hbase.client.trace.ConnectionSpanBuilder
 
org.apache.hadoop.hbase.client.ConnectionUtils - Class in org.apache.hadoop.hbase.client
Utility used by client connections.
connectTO - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
consistency - Variable in class org.apache.hadoop.hbase.client.Query
 
org.apache.hadoop.hbase.client.Consistency - Enum in org.apache.hadoop.hbase.client
Consistency defines the expected consistency level for an operation.
consolidate() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotManifest
 
org.apache.hadoop.hbase.thrift.Constants - Class in org.apache.hadoop.hbase.thrift
Thrift related constants
org.apache.hadoop.hbase.rest.Constants - Interface in org.apache.hadoop.hbase.rest
Common constants for org.apache.hadoop.hbase.rest
org.apache.hadoop.hbase.regionserver.ConstantSizeRegionSplitPolicy - Class in org.apache.hadoop.hbase.regionserver
A RegionSplitPolicy implementation which splits a region as soon as any of its store files exceeds a maximum configurable size.
ConstantSizeRegionSplitPolicy() - Constructor for class org.apache.hadoop.hbase.regionserver.ConstantSizeRegionSplitPolicy
 
constrainHttpMethods(ServletContextHandler, boolean) - Static method in class org.apache.hadoop.hbase.http.HttpServerUtil
Add constraints to a Jetty Context to disallow undesirable Http methods.
constructMaster(Class<? extends HMaster>, Configuration) - Static method in class org.apache.hadoop.hbase.master.HMaster
Utility for constructing an instance of the passed HMaster class.
consume() - Method in class org.apache.hadoop.hbase.quotas.RateLimiter
consume one available unit.
consume(long) - Method in class org.apache.hadoop.hbase.quotas.RateLimiter
consume amount available units, amount could be a negative number
consume(CompletableFuture<?>) - Static method in class org.apache.hadoop.hbase.util.FutureUtils
Log the error if the future indicates any failure.
consume(Future<?>) - Static method in class org.apache.hadoop.hbase.util.NettyFutureUtils
Log the error if the future indicates any failure.
consumeEventFromDisruptor(NamedQueuePayload) - Method in class org.apache.hadoop.hbase.namequeues.impl.BalancerDecisionQueueService
 
consumeEventFromDisruptor(NamedQueuePayload) - Method in class org.apache.hadoop.hbase.namequeues.impl.BalancerRejectionQueueService
 
consumeEventFromDisruptor(NamedQueuePayload) - Method in class org.apache.hadoop.hbase.namequeues.impl.SlowLogQueueService
This implementation is specific to slowLog event.
consumeEventFromDisruptor(NamedQueuePayload) - Method in interface org.apache.hadoop.hbase.namequeues.NamedQueueService
This implementation is generic for consuming records from LMAX disruptor and inserts records to EvictingQueue which is maintained by each ringbuffer provider.
consumeEventFromDisruptor(NamedQueuePayload) - Method in class org.apache.hadoop.hbase.namequeues.WALEventTrackerQueueService
 
consumeRead(long, long) - Method in interface org.apache.hadoop.hbase.quotas.QuotaLimiter
Removes or add back some read amount to the quota.
consumeRead(long, long) - Method in class org.apache.hadoop.hbase.quotas.TimeBasedLimiter
 
consumeWrite(long, long) - Method in interface org.apache.hadoop.hbase.quotas.QuotaLimiter
Removes or add back some write amount to the quota.
consumeWrite(long, long) - Method in class org.apache.hadoop.hbase.quotas.TimeBasedLimiter
 
contains(byte[]) - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.RowRange
 
contains(byte[], byte) - Static method in class org.apache.hadoop.hbase.util.Bytes
Return true if target is present as an element anywhere in the given array.
contains(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
Return true if target is present as an element anywhere in the given array.
contains(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.RowRange
 
contains(byte[], int, int, ByteBuff) - Method in class org.apache.hadoop.hbase.io.hfile.CompoundBloomFilter
 
contains(byte[], int, int, ByteBuff) - Method in interface org.apache.hadoop.hbase.util.BloomFilter
Check if the specified key is contained in the bloom filter.
contains(byte[], int, int, ByteBuff, int, int, Hash, int) - Static method in class org.apache.hadoop.hbase.util.BloomFilterUtil
 
contains(Object) - Method in class org.apache.hadoop.hbase.ipc.AdaptiveLifoCoDelCallQueue
 
contains(Object) - Method in class org.apache.hadoop.hbase.regionserver.CellSet
 
contains(Object) - Method in class org.apache.hadoop.hbase.thrift.CallQueue
 
contains(Object) - Method in class org.apache.hadoop.hbase.util.BoundedPriorityBlockingQueue
 
contains(Object) - Method in class org.apache.hadoop.hbase.util.SortedList
 
contains(String) - Static method in class org.apache.hadoop.hbase.io.compress.DictionaryCache
 
contains(Cell, ByteBuff, int, int, Hash, int, BloomType) - Static method in class org.apache.hadoop.hbase.util.BloomFilterUtil
 
contains(Cell, ByteBuff, BloomType) - Method in class org.apache.hadoop.hbase.io.hfile.CompoundBloomFilter
 
contains(Cell, ByteBuff, BloomType) - Method in interface org.apache.hadoop.hbase.util.BloomFilter
Check if the specified key is contained in the bloom filter.
contains(ReplicationPeerConfig, TableName) - Static method in class org.apache.hadoop.hbase.replication.ReplicationUtils
Deprecated.
Will be removed in HBase 3. Use ReplicationPeerConfig.needToReplicate(TableName) instead.
contains(T) - Method in class org.apache.hadoop.hbase.util.LossyCounting
 
containsAll(Collection<?>) - Method in class org.apache.hadoop.hbase.ipc.AdaptiveLifoCoDelCallQueue
 
containsAll(Collection<?>) - Method in class org.apache.hadoop.hbase.regionserver.CellSet
 
containsAll(Collection<?>) - Method in class org.apache.hadoop.hbase.thrift.CallQueue
 
containsAll(Collection<?>) - Method in class org.apache.hadoop.hbase.util.SortedList
 
containsBlock(BlockCacheKey) - Method in interface org.apache.hadoop.hbase.io.hfile.FirstLevelBlockCache
Whether the cache contains the block with specified cacheKey
containsBlock(BlockCacheKey) - Method in class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache
Whether the cache contains block with specified cacheKey
containsBlock(BlockCacheKey) - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
Whether the cache contains block with specified cacheKey
containsBlock(BlockCacheKey) - Method in class org.apache.hadoop.hbase.io.hfile.TinyLfuBlockCache
 
containsColumn(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Result
Checks for existence of a value for the specified column (empty or not).
containsColumn(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.client.Result
Checks for existence of a value for the specified column (empty or not).
containsEmptyColumn(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Result
Checks if the specified column contains an empty value (a zero-length byte array).
containsEmptyColumn(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.client.Result
Checks if the specified column contains an empty value (a zero-length byte array).
containsIgnoreMvccVersion(Collection<? extends Cell>, Collection<? extends Cell>) - Static method in class org.apache.hadoop.hbase.KeyValueTestUtil
Checks whether KeyValues from kvCollection2 are contained in kvCollection1.
containsKey(Object) - Method in class org.apache.hadoop.hbase.hbtop.Record
 
containsKey(Object) - Method in class org.apache.hadoop.hbase.io.hfile.HFileInfo
 
containsKey(Object) - Method in class org.apache.hadoop.hbase.regionserver.CellFlatMap
 
containsKey(Object) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
 
containsNonEmptyColumn(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Result
Checks if the specified column contains a non-empty value (not a zero-length byte array).
containsNonEmptyColumn(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.client.Result
Checks if the specified column contains a non-empty value (not a zero-length byte array).
containsOnlyHdfsEdits() - Method in class org.apache.hadoop.hbase.util.HbckRegionInfo
 
containsRange(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.client.RegionInfo
Returns true if the given inclusive range of rows is fully contained by this region.
containsRange(byte[], byte[]) - Method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
Returns true if the given inclusive range of rows is fully contained by this region.
containsRow(byte[]) - Method in interface org.apache.hadoop.hbase.client.RegionInfo
Returns true if the given row falls in this region.
containsRow(byte[]) - Method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
Returns true if the given row falls in this region.
containsServer(Address) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
Returns true if a server with hostPort is found
containsTable(TableName) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
 
containsValue(Object) - Method in class org.apache.hadoop.hbase.hbtop.Record
 
containsValue(Object) - Method in class org.apache.hadoop.hbase.io.hfile.HFileInfo
 
containsValue(Object) - Method in class org.apache.hadoop.hbase.regionserver.CellFlatMap
 
context - Variable in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
 
org.apache.hadoop.hbase.io.crypto.Context - Class in org.apache.hadoop.hbase.io.crypto
Crypto context.
Context() - Constructor for class org.apache.hadoop.hbase.ipc.RpcScheduler.Context
 
Context(Configuration, Configuration, FileSystem, String, UUID, ReplicationPeer, MetricsSource, TableDescriptors, Abortable) - Constructor for class org.apache.hadoop.hbase.replication.ReplicationEndpoint.Context
 
CONTEXT - Static variable in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
 
control(String, long) - Method in class org.apache.hadoop.hbase.regionserver.throttle.NoLimitThroughputController
 
control(String, long) - Method in class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareThroughputController
 
control(String, long) - Method in interface org.apache.hadoop.hbase.regionserver.throttle.ThroughputController
Control the throughput.
controller - Variable in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCaller
 
controlPerSize - Variable in class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareThroughputController
 
convert() - Method in class org.apache.hadoop.hbase.client.TableState
Covert to PB version of TableState
convert() - Method in enum org.apache.hadoop.hbase.client.TableState.State
Covert to PB version of State
convert() - Method in class org.apache.hadoop.hbase.ClusterId
Returns A pb instance to represent this instance.
convert() - Method in class org.apache.hadoop.hbase.io.Reference
 
convert() - Method in class org.apache.hadoop.hbase.master.RegionState
Convert a RegionState to an HBaseProtos.RegionState
convert() - Method in enum org.apache.hadoop.hbase.master.RegionState.State
Convert to protobuf ClusterStatusProtos.RegionState.State
convert(String) - Static method in class org.apache.hadoop.hbase.client.replication.ReplicationPeerConfigUtil
Convert string to TableCFs Object.
convert(Map<TableName, ? extends Collection<String>>) - Static method in class org.apache.hadoop.hbase.client.replication.ReplicationPeerConfigUtil
convert map to TableCFs Object
convert(DeserializationException) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Convert a DeserializationException to a more palatable KeeperException.
convert(HRegionInfo) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
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.
convert(ReplicationPeerConfig) - Static method in class org.apache.hadoop.hbase.client.replication.ReplicationPeerConfigUtil
 
convert(BackupProtos.BackupTableInfo) - Static method in class org.apache.hadoop.hbase.backup.BackupTableInfo
 
convert(ClusterIdProtos.ClusterId) - Static method in class org.apache.hadoop.hbase.ClusterId
Returns A ClusterId made from the passed in cid
convert(ClusterStatusProtos.RegionState) - Static method in class org.apache.hadoop.hbase.master.RegionState
Convert a protobuf HBaseProtos.RegionState to a RegionState
convert(ClusterStatusProtos.RegionState.State) - Static method in enum org.apache.hadoop.hbase.master.RegionState.State
Convert a protobuf HBaseProtos.RegionState.State to a RegionState.State
convert(FSProtos.Reference) - Static method in class org.apache.hadoop.hbase.io.Reference
 
convert(HBaseProtos.RegionInfo) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
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.
convert(HBaseProtos.TableState.State) - Static method in enum org.apache.hadoop.hbase.client.TableState.State
Covert from PB version of State
convert(ReplicationProtos.ReplicationPeer) - Static method in class org.apache.hadoop.hbase.client.replication.ReplicationPeerConfigUtil
 
convert(ReplicationProtos.TableCF[]) - Static method in class org.apache.hadoop.hbase.client.replication.ReplicationPeerConfigUtil
Convert TableCFs Object to String.
convert(TableName, HBaseProtos.TableState) - Static method in class org.apache.hadoop.hbase.client.TableState
Covert from PB version of TableState
CONVERT - Enum constant in enum org.apache.hadoop.hbase.backup.BackupRestoreConstants.BackupCommand
 
convert2Map(ReplicationProtos.TableCF[]) - Static method in class org.apache.hadoop.hbase.client.replication.ReplicationPeerConfigUtil
Convert tableCFs Object to Map.
convertAttributesToCsv(List<HBaseProtos.NameBytesPair>) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
Convert a list of NameBytesPair to a more readable CSV
convertByteArrayToBoolean(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
Converts a boolean expressed in a byte array to an actual boolean
convertByteArrayToInt(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
Converts an int expressed in a byte array to an actual int
convertByteArrayToLong(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
Converts a long expressed in a byte array to an actual long
convertResult(MasterProtos.GetProcedureResultResponse) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture
Convert the procedure result response to a specified type.
convertScanToString(Scan) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Writes the given scan into a Base64 encoded string.
convertStringToScan(String) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Converts the given Base64 string back into a Scan instance.
convertToBigInteger(byte[]) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.NumberStringSplit
Returns the BigInteger represented by the byte array
convertToByte(BigInteger) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.NumberStringSplit
Returns the bytes corresponding to the BigInteger
convertToByte(BigInteger, int) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.NumberStringSplit
Returns the bytes corresponding to the BigInteger
convertToBytes(BigInteger[]) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.NumberStringSplit
Returns an array of bytes corresponding to an array of BigIntegers
convertToProcedureMetrics(OperationMetrics) - Static method in class org.apache.hadoop.hbase.master.MetricsMaster
This is utility function that converts OperationMetrics to ProcedureMetrics.
convertToString(Map<TableName, ? extends Collection<String>>) - Static method in class org.apache.hadoop.hbase.client.replication.ReplicationPeerConfigUtil
 
convertToString(Set<String>) - Static method in class org.apache.hadoop.hbase.client.replication.ReplicationPeerConfigUtil
 
org.apache.hadoop.hbase.CoordinatedStateManager - Interface in org.apache.hadoop.hbase
Implementations of this interface will keep and return to clients implementations of classes providing API to execute coordinated operations.
COPROC - Static variable in class org.apache.hadoop.hbase.HBaseInterfaceAudience
 
coprocEnvironments - Variable in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
Ordered set of loaded coprocessors with lock
org.apache.hadoop.hbase.Coprocessor - Interface in org.apache.hadoop.hbase
Base interface for the 4 coprocessors - MasterCoprocessor, RegionCoprocessor, RegionServerCoprocessor, and WALCoprocessor.
COPROCESSOR_EXECUTION_STATISTICS - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
 
COPROCESSOR_EXECUTION_STATISTICS_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
 
org.apache.hadoop.hbase.Coprocessor.State - Enum in org.apache.hadoop.hbase
Lifecycle state of a given coprocessor instance.
org.apache.hadoop.hbase.util.CoprocessorClassLoader - Class in org.apache.hadoop.hbase.util
ClassLoader used to load classes for Coprocessor instances.
org.apache.hadoop.hbase.util.CoprocessorConfigurationUtil - Class in org.apache.hadoop.hbase.util
Helper class for coprocessor host when configuration changes.
org.apache.hadoop.hbase.client.CoprocessorDescriptor - Interface in org.apache.hadoop.hbase.client
CoprocessorDescriptor contains the details about how to build a coprocessor.
org.apache.hadoop.hbase.client.CoprocessorDescriptorBuilder - Class in org.apache.hadoop.hbase.client
Used to build the CoprocessorDescriptor
org.apache.hadoop.hbase.CoprocessorEnvironment<C extends org.apache.hadoop.hbase.Coprocessor> - Interface in org.apache.hadoop.hbase
Coprocessor environment state.
org.apache.hadoop.hbase.coprocessor.CoprocessorException - Exception in org.apache.hadoop.hbase.coprocessor
Thrown if a coprocessor encounters any exception.
CoprocessorException() - Constructor for exception org.apache.hadoop.hbase.coprocessor.CoprocessorException
Default Constructor
CoprocessorException(Class<?>, String) - Constructor for exception org.apache.hadoop.hbase.coprocessor.CoprocessorException
Constructor with a Class object and exception message.
CoprocessorException(String) - Constructor for exception org.apache.hadoop.hbase.coprocessor.CoprocessorException
Constructs the exception and supplies a string as the message
coprocessorHost - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
 
org.apache.hadoop.hbase.coprocessor.CoprocessorHost<C extends org.apache.hadoop.hbase.Coprocessor,E extends org.apache.hadoop.hbase.CoprocessorEnvironment<C>> - Class in org.apache.hadoop.hbase.coprocessor
Provides the common setup framework and runtime services for coprocessor invocation from HBase services.
CoprocessorHost(Abortable) - Constructor for class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
 
org.apache.hadoop.hbase.coprocessor.CoprocessorHost.ObserverGetter<C,O> - Interface in org.apache.hadoop.hbase.coprocessor
Implementations defined function to get an observer of type O from a coprocessor of type C.
org.apache.hadoop.hbase.coprocessor.CoprocessorHost.ObserverOperationWithoutResult<O> - Class in org.apache.hadoop.hbase.coprocessor
 
org.apache.hadoop.hbase.coprocessor.CoprocessorHost.ObserverOperationWithResult<O,R> - Class in org.apache.hadoop.hbase.coprocessor
 
org.apache.hadoop.hbase.tool.coprocessor.CoprocessorMethod - Class in org.apache.hadoop.hbase.tool.coprocessor
 
CoprocessorMethod(String) - Constructor for class org.apache.hadoop.hbase.tool.coprocessor.CoprocessorMethod
 
org.apache.hadoop.hbase.tool.coprocessor.CoprocessorMethods - Class in org.apache.hadoop.hbase.tool.coprocessor
 
CoprocessorMethods() - Constructor for class org.apache.hadoop.hbase.tool.coprocessor.CoprocessorMethods
 
org.apache.hadoop.hbase.ipc.CoprocessorRpcChannel - Interface in org.apache.hadoop.hbase.ipc
Base interface which provides clients with an RPC connection to call coprocessor endpoint Services.
org.apache.hadoop.hbase.ipc.CoprocessorRpcUtils - Class in org.apache.hadoop.hbase.ipc
Utilities for handling coprocessor rpc service calls.
org.apache.hadoop.hbase.ipc.CoprocessorRpcUtils.BlockingRpcCallback<R> - Class in org.apache.hadoop.hbase.ipc
Simple RpcCallback implementation providing a Future-like CoprocessorRpcUtils.BlockingRpcCallback.get() method, which will block util the instance's CoprocessorRpcUtils.BlockingRpcCallback.run(Object) method has been called.
COPROCESSORS_ENABLED_CONF_KEY - Static variable in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
 
coprocessorService() - Method in interface org.apache.hadoop.hbase.client.Admin
Creates and returns a RpcChannel instance connected to the active master.
coprocessorService() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
coprocessorService(byte[]) - Method in class org.apache.hadoop.hbase.client.HTable
 
coprocessorService(byte[]) - Method in interface org.apache.hadoop.hbase.client.Table
Creates and returns a RpcChannel instance connected to the table region containing the specified row.
coprocessorService(Class<T>, byte[], byte[], Batch.Call<T, R>) - Method in class org.apache.hadoop.hbase.client.HTable
 
coprocessorService(Class<T>, byte[], byte[], Batch.Call<T, R>) - Method in interface org.apache.hadoop.hbase.client.Table
Creates an instance of the given Service subclass for each table region spanning the range from the startKey row to endKey row (inclusive), and invokes the passed Batch.Call.call(T) method with each Service instance.
coprocessorService(Class<T>, byte[], byte[], Batch.Call<T, R>, Batch.Callback<R>) - Method in class org.apache.hadoop.hbase.client.HTable
 
coprocessorService(Class<T>, byte[], byte[], Batch.Call<T, R>, Batch.Callback<R>) - Method in interface org.apache.hadoop.hbase.client.Table
Creates an instance of the given Service subclass for each table region spanning the range from the startKey row to endKey row (inclusive), and invokes the passed Batch.Call.call(T) method with each Service instance.
coprocessorService(Function<RpcChannel, S>, ServiceCaller<S, R>) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Execute the given coprocessor call on the master.
coprocessorService(Function<RpcChannel, S>, ServiceCaller<S, R>, byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
Execute the given coprocessor call on the region which contains the given row.
coprocessorService(Function<RpcChannel, S>, ServiceCaller<S, R>, AsyncTable.CoprocessorCallback<R>) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
Execute a coprocessor call on the regions which are covered by a range.
coprocessorService(Function<RpcChannel, S>, ServiceCaller<S, R>, ServerName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Execute the given coprocessor call on the given region server.
coprocessorService(ServerName) - Method in interface org.apache.hadoop.hbase.client.Admin
Creates and returns a RpcChannel instance connected to the passed region server.
coprocessorService(ServerName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
org.apache.hadoop.hbase.coprocessor.CoprocessorService - Interface in org.apache.hadoop.hbase.coprocessor
Deprecated.
Since 2.0. Will be removed in 3.0
org.apache.hadoop.hbase.coprocessor.CoprocessorServiceBackwardCompatiblity - Class in org.apache.hadoop.hbase.coprocessor
Deprecated.
CoprocessorServiceBackwardCompatiblity() - Constructor for class org.apache.hadoop.hbase.coprocessor.CoprocessorServiceBackwardCompatiblity
Deprecated.
 
org.apache.hadoop.hbase.coprocessor.CoprocessorServiceBackwardCompatiblity.MasterCoprocessorService - Class in org.apache.hadoop.hbase.coprocessor
Deprecated.
 
org.apache.hadoop.hbase.coprocessor.CoprocessorServiceBackwardCompatiblity.RegionCoprocessorService - Class in org.apache.hadoop.hbase.coprocessor
Deprecated.
 
org.apache.hadoop.hbase.coprocessor.CoprocessorServiceBackwardCompatiblity.RegionServerCoprocessorService - Class in org.apache.hadoop.hbase.coprocessor
Deprecated.
 
coprocessorServiceOnAllRegionServers(AsyncAdmin, Function<RpcChannel, S>, ServiceCaller<S, R>) - Static method in class org.apache.hadoop.hbase.client.AsyncAdminClientUtils
Execute the given coprocessor call on all region servers.
org.apache.hadoop.hbase.tool.coprocessor.CoprocessorValidator - Class in org.apache.hadoop.hbase.tool.coprocessor
 
CoprocessorValidator() - Constructor for class org.apache.hadoop.hbase.tool.coprocessor.CoprocessorValidator
 
org.apache.hadoop.hbase.tool.coprocessor.CoprocessorViolation - Class in org.apache.hadoop.hbase.tool.coprocessor
 
CoprocessorViolation(String, CoprocessorViolation.Severity, String) - Constructor for class org.apache.hadoop.hbase.tool.coprocessor.CoprocessorViolation
 
CoprocessorViolation(String, CoprocessorViolation.Severity, String, Throwable) - Constructor for class org.apache.hadoop.hbase.tool.coprocessor.CoprocessorViolation
 
org.apache.hadoop.hbase.tool.coprocessor.CoprocessorViolation.Severity - Enum in org.apache.hadoop.hbase.tool.coprocessor
 
copy(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
Copy the byte array given in parameter and return an instance of a new byte array with the same length and the same content.
copy(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Copy the byte array given in parameter and return an instance of a new byte array with the same length and the same content.
copy(byte[], int, ByteBuffer, int, int) - Static method in class org.apache.hadoop.hbase.util.UnsafeAccess
Copies the bytes from given array's offset to length part into the given buffer.
copy(ByteBuffer, int, byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.UnsafeAccess
Copies specified number of bytes from given offset of src ByteBuffer to the dest array.
copy(ByteBuffer, int, ByteBuffer, int, int) - Static method in class org.apache.hadoop.hbase.util.UnsafeAccess
Copies specified number of bytes from given offset of src buffer into the dest buffer.
copy(BackupInfo, BackupManager, Configuration, BackupType, String[]) - Method in interface org.apache.hadoop.hbase.backup.BackupCopyJob
Copy backup data to destination
copy(ColumnFamilyDescriptor) - Static method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
copy(TableDescriptor) - Static method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
 
copy(TableName, TableDescriptor) - Static method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
 
COPY_FAILED - Enum constant in enum org.apache.hadoop.hbase.snapshot.ExportSnapshot.Counter
 
copyBufferToStream(DataOutput, ByteBuffer, int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
Deprecated.
Copy data from a buffer to an output stream.
copyBufferToStream(OutputStream, ByteBuffer, int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
Deprecated.
Copy data from a buffer to an output stream.
copyBytes() - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
Returns a copy of the bytes referred to by this writable
copyBytes() - Method in class org.apache.hadoop.hbase.util.Bytes
Returns a copy of the bytes referred to by this writable
copyCellInto(Cell) - Method in class org.apache.hadoop.hbase.regionserver.ImmutableMemStoreLAB
 
copyCellInto(Cell) - Method in interface org.apache.hadoop.hbase.regionserver.MemStoreLAB
Allocates slice in this LAB and copy the passed Cell into this area.
copyCellInto(Cell) - Method in class org.apache.hadoop.hbase.regionserver.MemStoreLABImpl
 
copyFamilyTo(Cell, byte[], int) - Static method in class org.apache.hadoop.hbase.CellUtil
Copies the family to the given byte[]
copyFamilyTo(Cell, ByteBuffer, int) - Static method in class org.apache.hadoop.hbase.CellUtil
Copies the family to the given bytebuffer
copyFilesParallel(FileSystem, Path, FileSystem, Path, Configuration, int) - Static method in class org.apache.hadoop.hbase.util.FSUtils
 
copyFrom(Result) - Method in class org.apache.hadoop.hbase.client.Result
Copy another Result into this one.
copyFromArrayToBuffer(ByteBuffer, byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
Deprecated.
Copies the bytes from given array's offset to length part into the given buffer.
copyFromArrayToBuffer(ByteBuffer, int, byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
Deprecated.
Copies bytes from given array's offset to length part into the given buffer.
copyFromBufferToArray(byte[], ByteBuffer, int, int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
Deprecated.
Copies specified number of bytes from given offset of 'in' ByteBuffer to the array.
copyFromBufferToBuffer(ByteBuffer, ByteBuffer) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
Deprecated.
Copy one buffer's whole data to another.
copyFromBufferToBuffer(ByteBuffer, ByteBuffer, int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
Deprecated.
Copy from one buffer to another from given offset.
copyFromBufferToBuffer(ByteBuffer, ByteBuffer, int, int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
Deprecated.
Copy from one buffer to another from given offset.
copyFromNext(BufferedDataBlockEncoder.SeekerState) - Method in class org.apache.hadoop.hbase.io.encoding.DiffKeyDeltaEncoder.DiffSeekerState
 
copyFromNext(BufferedDataBlockEncoder.SeekerState) - Method in class org.apache.hadoop.hbase.io.encoding.FastDiffDeltaEncoder.FastDiffSeekerState
 
copyFromStreamToBuffer(ByteBuffer, DataInputStream, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
Deprecated.
Copy the given number of bytes from the given stream and put it at the current position of the given buffer, updating the position in the buffer.
org.apache.hadoop.hbase.io.encoding.CopyKeyDataBlockEncoder - Class in org.apache.hadoop.hbase.io.encoding
Just copy data, do not do any kind of compression.
CopyKeyDataBlockEncoder() - Constructor for class org.apache.hadoop.hbase.io.encoding.CopyKeyDataBlockEncoder
 
copyKeyToNewByteBuffer(Cell) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
The position will be set to the beginning of the new ByteBuffer
copyOfRange(ByteBuffer, int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
Deprecated.
COPYONWRITE_ARRAYLIST - Static variable in class org.apache.hadoop.hbase.util.ClassSize
Overhead for CopyOnWriteArrayList
COPYONWRITE_ARRAYSET - Static variable in class org.apache.hadoop.hbase.util.ClassSize
Overhead for CopyOnWriteArraySet
org.apache.hadoop.hbase.types.CopyOnWriteArrayMap<K,V> - Class in org.apache.hadoop.hbase.types
A Map that keeps a sorted array in order to provide the concurrent map interface.
CopyOnWriteArrayMap() - Constructor for class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
 
CopyOnWriteArrayMap(Comparator<? super K>) - Constructor for class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
 
copyQualifierTo(Cell, byte[], int) - Static method in class org.apache.hadoop.hbase.CellUtil
Copies the qualifier to the given byte[]
copyQualifierTo(Cell, ByteBuffer, int) - Static method in class org.apache.hadoop.hbase.CellUtil
Copies the qualifier to the given bytebuffer
copyQuotaSnapshots() - Method in class org.apache.hadoop.hbase.quotas.RegionServerSpaceQuotaManager
Copies the last SpaceQuotaSnapshots that were recorded.
org.apache.hadoop.hbase.replication.CopyReplicationPeers - Class in org.apache.hadoop.hbase.replication
A tool for copying replication peer data across different replication peer storages.
CopyReplicationPeers(Configuration) - Constructor for class org.apache.hadoop.hbase.replication.CopyReplicationPeers
 
copyRow(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
Copies the row to a new byte[]
copyRowTo(Cell, byte[], int) - Static method in class org.apache.hadoop.hbase.CellUtil
Copies the row to the given byte[]
copyRowTo(Cell, ByteBuffer, int) - Static method in class org.apache.hadoop.hbase.CellUtil
Copies the row to the given bytebuffer
copyServerNames() - Method in class org.apache.hadoop.hbase.master.DeadServer
 
copySnapshotForScanner(Configuration, FileSystem, Path, Path, String) - Static method in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper
Copy the snapshot files for a snapshot scanner, discards meta changes.
org.apache.hadoop.hbase.mapreduce.CopyTable - Class in org.apache.hadoop.hbase.mapreduce
Tool used to copy a table to another one which can be on a different setup.
CopyTable() - Constructor for class org.apache.hadoop.hbase.mapreduce.CopyTable
 
copyTagsTo(Cell, byte[], int) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
Copies the tags info into the tag portion of the cell
copyTagsTo(Cell, ByteBuffer, int) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
Copies the tags info into the tag portion of the cell
copyTagTo(Cell, byte[], int) - Static method in class org.apache.hadoop.hbase.CellUtil
Deprecated.
As of HBase-2.0. Will be removed in HBase-3.0.
copyTagTo(Cell, ByteBuffer, int) - Static method in class org.apache.hadoop.hbase.CellUtil
Deprecated.
As of HBase-2.0. Will be removed in 3.0.
copyToNewArrays(Collection<ByteRange>) - Static method in class org.apache.hadoop.hbase.util.ByteRangeUtils
 
copyToNewByteArray(Cell) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
 
copyToNewKeyValue(Cell) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
copy the cell to create a new keyvalue
copyValueTo(Cell, byte[], int) - Static method in class org.apache.hadoop.hbase.CellUtil
Copies the value to the given byte[]
copyValueTo(Cell, ByteBuffer, int) - Static method in class org.apache.hadoop.hbase.CellUtil
Copies the value to the given bytebuffer
copyValueTo(Tag, byte[], int) - Static method in interface org.apache.hadoop.hbase.Tag
Copies the tag's value bytes to the given byte array
copyWritable(byte[], Writable) - Static method in class org.apache.hadoop.hbase.util.Writables
Copy one Writable to another.
copyWritable(Writable, Writable) - Static method in class org.apache.hadoop.hbase.util.Writables
Copy one Writable to another.
org.apache.hadoop.hbase.coprocessor.CoreCoprocessor - Annotation Type in org.apache.hadoop.hbase.coprocessor
Marker annotation that denotes Coprocessors that are core to HBase.
CORRUPT_DIR_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
 
org.apache.hadoop.hbase.snapshot.CorruptedSnapshotException - Exception in org.apache.hadoop.hbase.snapshot
Exception thrown when the found snapshot info from the filesystem is not valid.
CorruptedSnapshotException(String) - Constructor for exception org.apache.hadoop.hbase.snapshot.CorruptedSnapshotException
Snapshot was corrupt for some reason.
CorruptedSnapshotException(String, Exception) - Constructor for exception org.apache.hadoop.hbase.snapshot.CorruptedSnapshotException
Snapshot was corrupt for some reason.
CorruptedSnapshotException(String, SnapshotDescription) - Constructor for exception org.apache.hadoop.hbase.snapshot.CorruptedSnapshotException
Snapshot was corrupt for some reason.
org.apache.hadoop.hbase.io.hfile.CorruptHFileException - Exception in org.apache.hadoop.hbase.io.hfile
This exception is thrown when attempts to read an HFile fail due to corruption or truncation issues.
CorruptHFileException(String) - Constructor for exception org.apache.hadoop.hbase.io.hfile.CorruptHFileException
 
CorruptHFileException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.io.hfile.CorruptHFileException
 
count - Variable in class org.apache.hadoop.hbase.util.SimpleMovingAverage
 
counter(String) - Method in interface org.apache.hadoop.hbase.metrics.MetricRegistry
Get or construct a Counter used to track a mutable number.
org.apache.hadoop.hbase.util.Counter - Class in org.apache.hadoop.hbase.util
Deprecated.
since 2.0.0 and will be removed in 3.0.0. Use LongAdder instead.
org.apache.hadoop.hbase.metrics.Counter - Interface in org.apache.hadoop.hbase.metrics
A mutable number optimized for high concurrency counting.
Counter() - Constructor for class org.apache.hadoop.hbase.util.Counter
Deprecated.
 
Counter(long) - Constructor for class org.apache.hadoop.hbase.util.Counter
Deprecated.
 
countOfRegionServers() - Method in class org.apache.hadoop.hbase.master.ServerManager
Returns the count of active regionservers
CP_HTD_ATTR_INCLUSION_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
 
CP_HTD_ATTR_KEY_PATTERN - Static variable in class org.apache.hadoop.hbase.HConstants
Deprecated.
It is used internally. As of release 2.0.0, this will be removed in HBase 3.0.0.
CP_HTD_ATTR_VALUE_PARAM_KEY_PATTERN - Static variable in class org.apache.hadoop.hbase.HConstants
Deprecated.
It is used internally. As of release 2.0.0, this will be removed in HBase 3.0.0.
CP_HTD_ATTR_VALUE_PARAM_PATTERN - Static variable in class org.apache.hadoop.hbase.HConstants
Deprecated.
It is used internally. As of release 2.0.0, this will be removed in HBase 3.0.0.
CP_HTD_ATTR_VALUE_PARAM_VALUE_PATTERN - Static variable in class org.apache.hadoop.hbase.HConstants
Deprecated.
It is used internally. As of release 2.0.0, this will be removed in HBase 3.0.0.
CP_HTD_ATTR_VALUE_PATTERN - Static variable in class org.apache.hadoop.hbase.HConstants
Deprecated.
It is used internally. As of release 2.0.0, this will be removed in HBase 3.0.0.
CRC32 - Enum constant in enum org.apache.hadoop.hbase.util.ChecksumType
 
CRC32C - Enum constant in enum org.apache.hadoop.hbase.util.ChecksumType
 
create() - Static method in class org.apache.hadoop.hbase.HBaseConfiguration
Creates a Configuration with HBase resources
create() - Method in class org.apache.hadoop.hbase.io.hfile.HFile.WriterFactory
 
create() - Static method in class org.apache.hadoop.hbase.nio.RefCnt
Create an RefCnt with an initial reference count = 1.
create() - Static method in class org.apache.hadoop.hbase.RawCellBuilderFactory
Returns the cell that is created
create() - Static method in class org.apache.hadoop.hbase.regionserver.CreateStoreFileWriterParams
 
create() - Static method in class org.apache.hadoop.hbase.TagBuilderFactory
 
create() - Method in class org.apache.hadoop.hbase.util.RetryCounterFactory
 
create(byte[], int, int, byte[], int, int, byte[], int, int, long, byte[], int, int) - Method in class org.apache.hadoop.hbase.mapreduce.CellCreator
 
create(byte[], int, int, byte[], int, int, byte[], int, int, long, byte[], int, int, String) - Method in class org.apache.hadoop.hbase.mapreduce.CellCreator
Deprecated.
since 0.98.9
create(byte[], int, int, byte[], int, int, byte[], int, int, long, byte[], int, int, List<Tag>) - Method in class org.apache.hadoop.hbase.mapreduce.CellCreator
 
create(byte[], String, String, String) - Static method in class org.apache.hadoop.hbase.mob.MobFileName
Creates an instance of MobFileName
create(int, DataInput) - Static method in class org.apache.hadoop.hbase.KeyValue
Create a KeyValue reading length from in
create(int, DataInput) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
Create a KeyValue reading length from in
create(A, B, C) - Static method in class org.apache.hadoop.hbase.util.Triple
 
create(DataInput) - Static method in class org.apache.hadoop.hbase.KeyValue
Create a KeyValue reading from in
create(DataInput) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
Where to read bytes from.
create(String) - Static method in class org.apache.hadoop.hbase.mob.MobFileName
Creates an instance of MobFileName.
create(String) - Static method in class org.apache.hadoop.hbase.NamespaceDescriptor
 
create(String, byte[], List<ACL>, CreateMode) - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
NONSEQUENTIAL create is idempotent operation.
create(String, String, String, long, String) - Static method in class org.apache.hadoop.hbase.KeyValueTestUtil
 
create(String, String, String, long, KeyValue.Type, String) - Static method in class org.apache.hadoop.hbase.KeyValueTestUtil
 
create(String, String, String, String) - Static method in class org.apache.hadoop.hbase.mob.MobFileName
Creates an instance of MobFileName
create(String, MetricsHBaseServerWrapper) - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceFactoryImpl
 
create(List<Cell>) - Static method in class org.apache.hadoop.hbase.client.Result
Instantiate a Result with the specified List of KeyValues.
create(List<Cell>, Boolean) - Static method in class org.apache.hadoop.hbase.client.Result
 
create(List<Cell>, Boolean, boolean) - Static method in class org.apache.hadoop.hbase.client.Result
 
create(List<Cell>, Boolean, boolean, boolean) - Static method in class org.apache.hadoop.hbase.client.Result
 
create(Configuration) - Static method in class org.apache.hadoop.hbase.client.backoff.ClientBackoffPolicyFactory
 
create(Configuration) - Static method in class org.apache.hadoop.hbase.client.RequestControllerFactory
Constructs a RequestController.
create(Configuration) - Static method in class org.apache.hadoop.hbase.client.ServerStatisticTracker
 
create(Configuration) - Static method in class org.apache.hadoop.hbase.HBaseConfiguration
Creates a Configuration with HBase resources
create(Configuration) - Method in class org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshotNotifierFactory
Instantiates the SpaceQuotaSnapshotNotifier implementation as defined in the configuration provided.
create(Configuration, boolean) - Static method in class org.apache.hadoop.hbase.io.ByteBuffAllocator
Initialize an ByteBuffAllocator which will try to allocate ByteBuffers from off-heap if reservoir is enabled and the reservoir has enough buffers, otherwise the allocator will just allocate the insufficient buffers from on-heap to meet the requirement.
create(Configuration, boolean, StoreContext) - Static method in class org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileTrackerFactory
 
create(Configuration, String) - Static method in class org.apache.hadoop.hbase.io.asyncfs.monitor.StreamSlowMonitor
 
create(Configuration, String, CompressionContext) - Static method in class org.apache.hadoop.hbase.regionserver.wal.WALCellCodec
Create and setup a WALCellCodec from the cellCodecClsName and CompressionContext, if cellCodecClsName is specified.
create(Configuration, FileSystem, Path, String, String, String, TableName, String, String, boolean) - Static method in class org.apache.hadoop.hbase.io.HFileLink
Create a new HFileLink
create(Configuration, FileSystem, Path, FsPermission, InetSocketAddress[]) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Create the specified file on the filesystem.
create(Configuration, FileSystem, Path, RegionInfo, String) - Static method in class org.apache.hadoop.hbase.io.HFileLink
Create a new HFileLink
create(Configuration, FileSystem, Path, RegionInfo, String, boolean) - Static method in class org.apache.hadoop.hbase.io.HFileLink
Create a new HFileLink
create(Configuration, FileSystem, Path, SnapshotProtos.SnapshotDescription, ForeignExceptionSnare) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotManifest
Return a SnapshotManifest instance, used for writing a snapshot.
create(Configuration, FileSystem, Path, SnapshotProtos.SnapshotDescription, ForeignExceptionSnare, MonitoredTask) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotManifest
 
create(Configuration, FileSystem, Path, TableName, String, String) - Static method in class org.apache.hadoop.hbase.io.HFileLink
Create a new HFileLink
create(Configuration, FileSystem, Path, TableName, String, String, boolean) - Static method in class org.apache.hadoop.hbase.io.HFileLink
Create a new HFileLink.
create(Configuration, TableDescriptor, ColumnFamilyDescriptor, HRegionFileSystem) - Static method in class org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileTrackerFactory
Used at master side when splitting/merging regions, as we do not have a Store, thus no StoreContext at master side.
create(Configuration, PriorityFunction) - Method in class org.apache.hadoop.hbase.regionserver.FifoRpcSchedulerFactory
Deprecated.
create(Configuration, PriorityFunction) - Method in interface org.apache.hadoop.hbase.regionserver.RpcSchedulerFactory
Deprecated.
since 1.0.0.
create(Configuration, PriorityFunction) - Method in class org.apache.hadoop.hbase.regionserver.SimpleRpcSchedulerFactory
Deprecated.
since 1.0.0.
create(Configuration, PriorityFunction, Abortable) - Method in class org.apache.hadoop.hbase.regionserver.FifoRpcSchedulerFactory
 
create(Configuration, PriorityFunction, Abortable) - Method in class org.apache.hadoop.hbase.regionserver.MasterFifoRpcSchedulerFactory
 
create(Configuration, PriorityFunction, Abortable) - Method in interface org.apache.hadoop.hbase.regionserver.RpcSchedulerFactory
Constructs a RpcScheduler.
create(Configuration, PriorityFunction, Abortable) - Method in class org.apache.hadoop.hbase.regionserver.SimpleRpcSchedulerFactory
 
create(Configuration, CompressionContext) - Static method in class org.apache.hadoop.hbase.regionserver.wal.WALCellCodec
Create and setup a WALCellCodec from the CompressionContext.
create(FileSystem, Path, Configuration, CacheConfig) - Static method in class org.apache.hadoop.hbase.mob.CachedMobFile
 
create(FileSystem, Path, Configuration, CacheConfig) - Static method in class org.apache.hadoop.hbase.mob.MobFile
Creates an instance of the MobFile.
create(FileSystem, Path, FsPermission, boolean) - Static method in class org.apache.hadoop.hbase.util.CommonFSUtils
Create the specified file on the filesystem.
create(Cell[]) - Static method in class org.apache.hadoop.hbase.client.Result
Instantiate a Result with the specified array of KeyValues.
create(Cell[], Boolean, boolean) - Static method in class org.apache.hadoop.hbase.client.Result
 
create(Cell[], Boolean, boolean, boolean) - Static method in class org.apache.hadoop.hbase.client.Result
 
create(CellBuilderType) - Static method in class org.apache.hadoop.hbase.CellBuilderFactory
Create a CellBuilder instance.
create(CellBuilderType) - Static method in class org.apache.hadoop.hbase.ExtendedCellBuilderFactory
Allows creating a cell with the given CellBuilderType.
create(Connection, String, BackupRequest) - Static method in class org.apache.hadoop.hbase.backup.BackupClientFactory
 
create(Scan, ScanInfo, NavigableSet<byte[]>, long, long, RegionCoprocessorHost) - Static method in class org.apache.hadoop.hbase.regionserver.querymatcher.UserScanQueryMatcher
 
create(Scan, ScanInfo, ColumnTracker, boolean, long, long) - Static method in class org.apache.hadoop.hbase.regionserver.querymatcher.RawScanQueryMatcher
 
create(Scan, ScanInfo, ColumnTracker, DeleteTracker, boolean, long, long) - Static method in class org.apache.hadoop.hbase.regionserver.querymatcher.NormalUserScanQueryMatcher
 
create(TableDescriptor, Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.RegionSplitRestriction
Create the RegionSplitRestriction configured for the given table.
create(ByteBuffAllocator.Recycler) - Static method in class org.apache.hadoop.hbase.nio.RefCnt
 
create(MetricsMasterWrapper) - Method in interface org.apache.hadoop.hbase.master.MetricsMasterProcSourceFactory
 
create(MetricsMasterWrapper) - Method in class org.apache.hadoop.hbase.master.MetricsMasterProcSourceFactoryImpl
 
create(MetricsMasterWrapper) - Method in interface org.apache.hadoop.hbase.master.MetricsMasterQuotaSourceFactory
 
create(MetricsMasterWrapper) - Method in class org.apache.hadoop.hbase.master.MetricsMasterQuotaSourceFactoryImpl
 
create(MetricsMasterWrapper) - Method in interface org.apache.hadoop.hbase.master.MetricsMasterSourceFactory
 
create(MetricsMasterWrapper) - Method in class org.apache.hadoop.hbase.master.MetricsMasterSourceFactoryImpl
 
create(MetricRegistryInfo) - Method in class org.apache.hadoop.hbase.metrics.MetricRegistries
Create or return MetricRegistry with the given info.
create(MetricRegistryInfo) - Method in interface org.apache.hadoop.hbase.metrics.MetricRegistryFactory
Create a MetricRegistry from the given MetricRegistryInfo
create(NamespaceDescriptor) - Static method in class org.apache.hadoop.hbase.NamespaceDescriptor
 
create(HRegion, Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.FlushPolicyFactory
Create the FlushPolicy configured for the given table.
create(HRegion, Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.RegionSplitPolicy
Create the RegionSplitPolicy configured for the given table.
create(HStore, Configuration, CellComparator) - Static method in class org.apache.hadoop.hbase.regionserver.StoreEngine
Create the StoreEngine configured for the given Store.
create(RegionServerServices, Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.throttle.CompactionThroughputControllerFactory
 
create(RegionServerServices, Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.throttle.FlushThroughputControllerFactory
 
create(RegionServerServices, TableName, SpaceQuotaSnapshot) - Method in class org.apache.hadoop.hbase.quotas.SpaceViolationPolicyEnforcementFactory
Constructs the appropriate SpaceViolationPolicyEnforcement for tables that are in violation of their space quota.
create(ScanInfo, ScanType, long, long, long, long, byte[], byte[], RegionCoprocessorHost) - Static method in class org.apache.hadoop.hbase.regionserver.querymatcher.CompactionScanQueryMatcher
 
create(TimeRangeTracker.Type) - Static method in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker
 
create(TimeRangeTracker.Type, long, long) - Static method in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker
 
create(TimeRangeTracker.Type, TimeRangeTracker) - Static method in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker
 
create(TestingHBaseClusterOption) - Static method in interface org.apache.hadoop.hbase.testing.TestingHBaseCluster
Create a TestingHBaseCluster.
create(UserGroupInformation) - Static method in class org.apache.hadoop.hbase.security.User
Wraps an underlying UserGroupInformation instance.
create(UserGroupInformation) - Method in class org.apache.hadoop.hbase.security.UserProvider
Wraps an underlying UserGroupInformation instance.
CREATE - Enum constant in enum org.apache.hadoop.hbase.backup.BackupRestoreConstants.BackupCommand
 
CREATE_TABLE_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv
 
createACL(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZKWatcher
 
createACL(String, boolean) - Method in class org.apache.hadoop.hbase.zookeeper.ZKWatcher
 
createActiveMasterManager(ZKWatcher, ServerName, Server) - Method in class org.apache.hadoop.hbase.master.HMaster
Protected to have custom implementations in tests override the default ActiveMaster implementation.
createAndFailSilent(String, byte[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp
Returns a createAndFailSilent ZKUtilOp
createAndFailSilent(ZKWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Creates the specified node, iff the node does not exist.
createAndFailSilent(ZKWatcher, String, byte[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Creates the specified node containing specified data, iff the node does not exist.
createAndPrepare(E) - Static method in class org.apache.hadoop.hbase.coprocessor.ObserverContextImpl
Deprecated.
createAndWatch(ZKWatcher, String, byte[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Creates the specified node with the specified data and watches it.
createAnother() - Method in class org.apache.hadoop.hbase.util.BloomFilterChunk
Creates another similar Bloom filter.
createAssignmentManager(MasterServices, MasterRegion) - Method in class org.apache.hadoop.hbase.master.HMaster
 
CreateAsyncCallback() - Constructor for class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination.CreateAsyncCallback
 
createAsyncConnection() - Static method in class org.apache.hadoop.hbase.client.ConnectionFactory
Call ConnectionFactory.createAsyncConnection(Configuration) using default HBaseConfiguration.
createAsyncConnection(Configuration) - Static method in class org.apache.hadoop.hbase.client.ConnectionFactory
Call ConnectionFactory.createAsyncConnection(Configuration, User) using the given conf and a User object created by UserProvider.
createAsyncConnection(Configuration, User) - Static method in class org.apache.hadoop.hbase.client.ConnectionFactory
Create a new AsyncConnection instance using the passed conf and user.
createAsyncConnection(Configuration, User, Map<String, byte[]>) - Static method in class org.apache.hadoop.hbase.client.ConnectionFactory
Create a new AsyncConnection instance using the passed conf and user.
createAsyncWriter(Configuration, FileSystem, Path, boolean, long, EventLoopGroup, Class<? extends Channel>, StreamSlowMonitor) - Static method in class org.apache.hadoop.hbase.wal.AsyncFSWALProvider
Public because of AsyncFSWAL.
createAsyncWriter(Configuration, FileSystem, Path, boolean, EventLoopGroup, Class<? extends Channel>) - Static method in class org.apache.hadoop.hbase.wal.AsyncFSWALProvider
Public because of AsyncFSWAL.
createBlockCache(Configuration) - Static method in class org.apache.hadoop.hbase.io.hfile.BlockCacheFactory
 
createBlockingRpcChannel(ServerName, User, int) - Method in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
createBlockingRpcChannel(ServerName, User, int) - Method in interface org.apache.hadoop.hbase.ipc.RpcClient
Creates a "channel" that can be used by a blocking protobuf service.
createBottomReference(byte[]) - Static method in class org.apache.hadoop.hbase.io.Reference
Returns A Reference that points at the bottom half of a an hfile
createBulkLoadEvent(RegionInfo, WALProtos.BulkLoadDescriptor) - Static method in class org.apache.hadoop.hbase.wal.WALEdit
Create a bulk loader WALEdit
createBySize(int, double, int, int, BloomType) - Static method in class org.apache.hadoop.hbase.util.BloomFilterUtil
Creates a Bloom filter chunk of the given size.
createCacheConf(ColumnFamilyDescriptor) - Method in class org.apache.hadoop.hbase.regionserver.HStore
Creates the cache config.
createCell(byte[]) - Static method in class org.apache.hadoop.hbase.CellUtil
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use CellBuilder instead
createCell(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.CellUtil
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use CellBuilder instead
createCell(byte[], byte[], byte[]) - Static method in class org.apache.hadoop.hbase.CellUtil
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use CellBuilder instead
createCell(byte[], byte[], byte[], long, byte, byte[]) - Static method in class org.apache.hadoop.hbase.CellUtil
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use CellBuilder instead
createCell(byte[], byte[], byte[], long, byte, byte[], byte[], long) - Static method in class org.apache.hadoop.hbase.CellUtil
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use ExtendedCellBuilder instead
createCell(byte[], byte[], byte[], long, byte, byte[], long) - Static method in class org.apache.hadoop.hbase.CellUtil
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use ExtendedCellBuilder instead
createCell(byte[], byte[], byte[], long, KeyValue.Type, byte[], byte[]) - Static method in class org.apache.hadoop.hbase.CellUtil
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use ExtendedCellBuilder instead
createCell(byte[], int, int) - Method in class org.apache.hadoop.hbase.codec.KeyValueCodec.ByteBuffKeyValueDecoder
 
createCell(byte[], int, int) - Method in class org.apache.hadoop.hbase.codec.KeyValueCodecWithTags.ByteBuffKeyValueDecoder
 
createCell(byte[], int, int, byte[], int, int, byte[], int, int) - Static method in class org.apache.hadoop.hbase.CellUtil
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use CellBuilder instead
createCell(ByteBuffer, int, int) - Method in class org.apache.hadoop.hbase.codec.KeyValueCodec.ByteBuffKeyValueDecoder
 
createCell(ByteBuffer, int, int) - Method in class org.apache.hadoop.hbase.codec.KeyValueCodecWithTags.ByteBuffKeyValueDecoder
 
createCell(Cell, byte[]) - Static method in class org.apache.hadoop.hbase.CellUtil
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0.
createCell(Cell, byte[]) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
Returns A new cell which is having the extra tags also added to it.
createCell(Cell, byte[], byte[]) - Static method in class org.apache.hadoop.hbase.CellUtil
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0.
createCell(Cell, byte[], byte[]) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
 
createCell(Cell, List<Tag>) - Static method in class org.apache.hadoop.hbase.CellUtil
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0.
createCell(Cell, List<Tag>) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
Returns A new cell which is having the extra tags also added to it.
createCell(Cell, List<Tag>) - Static method in interface org.apache.hadoop.hbase.RawCell
Returns A new cell which is having the extra tags also added to it.
createCellScanner(Iterable<Cell>) - Static method in class org.apache.hadoop.hbase.CellUtil
Returns CellScanner interface over cellIterable
createCellScanner(Iterator<Cell>) - Static method in class org.apache.hadoop.hbase.CellUtil
Returns CellScanner interface over cellIterable or null if cells is null
createCellScanner(List<? extends CellScannable>) - Static method in class org.apache.hadoop.hbase.CellUtil
Returns CellScanner interface over cellIterables
createCellScanner(NavigableMap<byte[], List<Cell>>) - Static method in class org.apache.hadoop.hbase.CellUtil
Flatten the map of cells out under the CellScanner
createCellScanner(Cell[]) - Static method in class org.apache.hadoop.hbase.CellUtil
Returns CellScanner interface over cellArray
createCleanupScheduledChore(Stoppable) - Method in class org.apache.hadoop.hbase.regionserver.ServerNonceManager
Creates a scheduled chore that is used to clean up old nonces.
createClient(Configuration, String) - Static method in class org.apache.hadoop.hbase.ipc.RpcClientFactory
Helper method for tests only.
createClient(Configuration, String, SocketAddress, MetricsConnection, Map<String, byte[]>) - Static method in class org.apache.hadoop.hbase.ipc.RpcClientFactory
Creates a new RpcClient by the class defined in the configuration or falls back to RpcClientImpl
createClient(Configuration, String, MetricsConnection) - Static method in class org.apache.hadoop.hbase.ipc.RpcClientFactory
Creates a new RpcClient by the class defined in the configuration or falls back to RpcClientImpl
createClient(Configuration, String, MetricsConnection, Map<String, byte[]>) - Static method in class org.apache.hadoop.hbase.ipc.RpcClientFactory
Creates a new RpcClient by the class defined in the configuration or falls back to RpcClientImpl
createClusterConf(Configuration, String) - Static method in class org.apache.hadoop.hbase.HBaseConfiguration
Generates a Configuration instance by applying the ZooKeeper cluster key to the base Configuration.
createClusterConf(Configuration, String, String) - Static method in class org.apache.hadoop.hbase.HBaseConfiguration
Generates a Configuration instance by applying property overrides prefixed by a cluster profile key to the base Configuration.
createClusterConnection() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
createCompaction() - Method in class org.apache.hadoop.hbase.regionserver.DateTieredStoreEngine
 
createCompaction() - Method in class org.apache.hadoop.hbase.regionserver.DefaultStoreEngine
 
createCompaction() - Method in class org.apache.hadoop.hbase.regionserver.StoreEngine
Creates an instance of a compaction context specific to this engine.
createCompaction() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreEngine
 
createCompaction(RegionInfo, WALProtos.CompactionDescriptor) - Static method in class org.apache.hadoop.hbase.wal.WALEdit
Returns A Marker WALEdit that has c serialized as its value
createCompactionPolicy(Configuration, HStore) - Method in class org.apache.hadoop.hbase.regionserver.DefaultStoreEngine
 
createCompactionState(CompactionState) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
 
createCompactionState(AdminProtos.GetRegionInfoResponse.CompactionState) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
Creates CompactionState from AdminProtos.GetRegionInfoResponse.CompactionState state
createCompactionStateForRegionLoad(CompactionState) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
 
createCompactionStateForRegionLoad(ClusterStatusProtos.RegionLoad.CompactionState) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
Creates CompactionState from ClusterStatusProtos.RegionLoad.CompactionState state
createCompactor(Configuration, HStore) - Method in class org.apache.hadoop.hbase.mob.MobStoreEngine
Creates the DefaultMobCompactor.
createCompactor(Configuration, HStore) - Method in class org.apache.hadoop.hbase.regionserver.DefaultStoreEngine
 
createComparator(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
Parses a comparator of the form comparatorType:comparatorValue form and returns a comparator
createCompareOp(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
Deprecated.
Since 2.0

createCompareOperator(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
Takes a compareOperator symbol as a byte array and returns the corresponding CompareOperator
createCompleteResult(Iterable<Result>) - Static method in class org.apache.hadoop.hbase.client.Result
Forms a single result from the partial results in the partialResults list.
createComponents(Configuration, HStore, CellComparator) - Method in class org.apache.hadoop.hbase.regionserver.DateTieredStoreEngine
 
createComponents(Configuration, HStore, CellComparator) - Method in class org.apache.hadoop.hbase.regionserver.DefaultStoreEngine
 
createComponents(Configuration, HStore, CellComparator) - Method in class org.apache.hadoop.hbase.regionserver.StoreEngine
Create the StoreEngine's components.
createComponents(Configuration, HStore, CellComparator) - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreEngine
 
createComponentsOnce(Configuration, HStore, CellComparator) - Method in class org.apache.hadoop.hbase.regionserver.StoreEngine
 
createCompositeImmutableSegment(CellComparator, List<ImmutableSegment>) - Method in class org.apache.hadoop.hbase.regionserver.SegmentFactory
 
createCompositeKey(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.mapreduce.MultiTableHFileOutputFormat
Creates a composite key to use as a mapper output key when using MultiTableHFileOutputFormat.configureIncrementaLoad to set up bulk ingest job
createCompositeKey(byte[], ImmutableBytesWritable) - Static method in class org.apache.hadoop.hbase.mapreduce.MultiTableHFileOutputFormat
Alternate api which accepts an ImmutableBytesWritable for the suffix
createCompositeKey(String, ImmutableBytesWritable) - Static method in class org.apache.hadoop.hbase.mapreduce.MultiTableHFileOutputFormat
Alternate api which accepts a String for the tableName and ImmutableBytesWritable for the suffix
createCompressionStream(OutputStream, Compressor, int) - Method in enum org.apache.hadoop.hbase.io.compress.Compression.Algorithm
 
createConf(Configuration, TableDescriptor) - Method in class org.apache.hadoop.hbase.regionserver.storefiletracker.ModifyColumnFamilyStoreFileTrackerProcedure
 
createConf(Configuration, TableDescriptor) - Method in class org.apache.hadoop.hbase.regionserver.storefiletracker.ModifyStoreFileTrackerProcedure
 
createConf(Configuration, TableDescriptor) - Method in class org.apache.hadoop.hbase.regionserver.storefiletracker.ModifyTableStoreFileTrackerProcedure
 
createConnection() - Static method in class org.apache.hadoop.hbase.client.ConnectionFactory
Create a new Connection instance using default HBaseConfiguration.
createConnection(Configuration) - Static method in class org.apache.hadoop.hbase.client.ConnectionFactory
Create a new Connection instance using the passed conf instance.
createConnection(Configuration) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment
Creates a cluster connection using the passed Configuration.
createConnection(Configuration) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment
Creates a cluster connection using the passed Configuration.
createConnection(Configuration) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionServerCoprocessorEnvironment
Creates a cluster connection using the passed Configuration.
createConnection(Configuration) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
createConnection(Configuration) - Method in interface org.apache.hadoop.hbase.Server
 
createConnection(Configuration, ExecutorService) - Static method in class org.apache.hadoop.hbase.client.ConnectionFactory
Create a new Connection instance using the passed conf instance.
createConnection(Configuration, ExecutorService, User) - Static method in class org.apache.hadoop.hbase.client.ConnectionFactory
Create a new Connection instance using the passed conf instance.
createConnection(Configuration, ExecutorService, User, Map<String, byte[]>) - Static method in class org.apache.hadoop.hbase.client.ConnectionFactory
Create a new Connection instance using the passed conf instance.
createConnection(Configuration, User) - Static method in class org.apache.hadoop.hbase.client.ConnectionFactory
Create a new Connection instance using the passed conf instance.
createConnection(ConnectionId) - Method in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
Not connected.
createConnection(ConnectionId) - Method in class org.apache.hadoop.hbase.ipc.BlockingRpcClient
Creates a connection.
createConnection(ConnectionId) - Method in class org.apache.hadoop.hbase.ipc.NettyRpcClient
 
createContextName(String) - Static method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceFactory
From the name of the class that's starting up create the context that an IPC source should register itself.
createCryptoAES(RPCProtos.CryptoCipherMeta, Configuration) - Static method in class org.apache.hadoop.hbase.security.EncryptionUtil
Helper to create an instance of CryptoAES.
createCursor(byte[]) - Static method in class org.apache.hadoop.hbase.client.ClientUtil
 
createCursorResult(Cursor) - Static method in class org.apache.hadoop.hbase.client.Result
 
createDecompressionStream(InputStream, Decompressor, int) - Method in enum org.apache.hadoop.hbase.io.compress.Compression.Algorithm
 
createDecryptionStream(InputStream) - Method in class org.apache.hadoop.hbase.io.crypto.aes.AESDecryptor
 
createDecryptionStream(InputStream) - Method in class org.apache.hadoop.hbase.io.crypto.aes.CommonsCryptoAESDecryptor
 
createDecryptionStream(InputStream) - Method in interface org.apache.hadoop.hbase.io.crypto.Decryptor
Create a stream for decryption
createDecryptionStream(InputStream, Context, byte[]) - Method in class org.apache.hadoop.hbase.io.crypto.aes.AES
 
createDecryptionStream(InputStream, Context, byte[]) - Method in class org.apache.hadoop.hbase.io.crypto.aes.CommonsCryptoAES
 
createDecryptionStream(InputStream, Context, byte[]) - Method in class org.apache.hadoop.hbase.io.crypto.Cipher
Create a decrypting input stream given a context and IV
createDecryptionStream(InputStream, Decryptor) - Method in class org.apache.hadoop.hbase.io.crypto.aes.AES
 
createDecryptionStream(InputStream, Decryptor) - Method in class org.apache.hadoop.hbase.io.crypto.aes.CommonsCryptoAES
 
createDecryptionStream(InputStream, Decryptor) - Method in class org.apache.hadoop.hbase.io.crypto.Cipher
Create a decrypting output stream given an initialized decryptor
createDeleteBloomAtWrite(Configuration, CacheConfig, int, HFile.Writer) - Static method in class org.apache.hadoop.hbase.util.BloomFilterFactory
Creates a new Delete Family Bloom filter at the time of HStoreFile writing.
createDestinationServersList() - Method in class org.apache.hadoop.hbase.master.ServerManager
Calls ServerManager.createDestinationServersList(java.util.List<org.apache.hadoop.hbase.ServerName>) without server to exclude.
createDestinationServersList(List<ServerName>) - Method in class org.apache.hadoop.hbase.master.ServerManager
Creates a list of possible destinations for a region.
createEncryptionContext(Configuration, ColumnFamilyDescriptor) - Static method in class org.apache.hadoop.hbase.security.EncryptionUtil
Helper to create an encyption context.
createEncryptionStream(OutputStream) - Method in class org.apache.hadoop.hbase.io.crypto.aes.AESEncryptor
 
createEncryptionStream(OutputStream) - Method in class org.apache.hadoop.hbase.io.crypto.aes.CommonsCryptoAESEncryptor
 
createEncryptionStream(OutputStream) - Method in interface org.apache.hadoop.hbase.io.crypto.Encryptor
Create a stream for encryption
createEncryptionStream(OutputStream, Context, byte[]) - Method in class org.apache.hadoop.hbase.io.crypto.aes.AES
 
createEncryptionStream(OutputStream, Context, byte[]) - Method in class org.apache.hadoop.hbase.io.crypto.aes.CommonsCryptoAES
 
createEncryptionStream(OutputStream, Context, byte[]) - Method in class org.apache.hadoop.hbase.io.crypto.Cipher
Create an encrypting output stream given a context and IV
createEncryptionStream(OutputStream, Encryptor) - Method in class org.apache.hadoop.hbase.io.crypto.aes.AES
 
createEncryptionStream(OutputStream, Encryptor) - Method in class org.apache.hadoop.hbase.io.crypto.aes.CommonsCryptoAES
 
createEncryptionStream(OutputStream, Encryptor) - Method in class org.apache.hadoop.hbase.io.crypto.Cipher
Create an encrypting output stream given an initialized encryptor
createEnvironment(C, int, int, Configuration) - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
Called when a new Coprocessor class is loaded
createEnvironment(MasterCoprocessor, int, int, Configuration) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
 
createEnvironment(RegionCoprocessor, int, int, Configuration) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
 
createEnvironment(RegionServerCoprocessor, int, int, Configuration) - Method in class org.apache.hadoop.hbase.regionserver.RegionServerCoprocessorHost
 
createEnvironment(WALCoprocessor, int, int, Configuration) - Method in class org.apache.hadoop.hbase.regionserver.wal.WALCoprocessorHost
 
createEphemeralNodeAndWatch(ZKWatcher, String, byte[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Set the specified znode to be an ephemeral node carrying the specified data.
createEphemeralZNode(String, byte[]) - Method in class org.apache.hadoop.hbase.chaos.ChaosAgent
Function to create EPHEMERAL ZNODE with given path and data as params.
createEventLoopPerClient(Configuration) - Static method in class org.apache.hadoop.hbase.ipc.NettyRpcClientConfigHelper
The NettyRpcClient will create its own NioEventLoopGroup.
createExceptionString(Class) - Static method in class org.apache.hadoop.hbase.CompatibilityFactory
 
createExecutor(BlockingQueue<Runnable>, int, int) - Method in class org.apache.hadoop.hbase.thrift.ThriftServer
 
createExecutor(Configuration, String) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotManifest
 
createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
 
createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
 
createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.ColumnPrefixFilter
 
createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
 
createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.ColumnValueFilter
Creating this filter by reflection, it is used by ParseFilter,
createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
 
createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.FamilyFilter
 
createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.FilterBase
Given the filter's arguments it constructs the filter
createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
 
createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.InclusiveStopFilter
 
createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter
 
createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
 
createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.PageFilter
 
createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.PrefixFilter
 
createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.QualifierFilter
 
createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.RowFilter
 
createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter
 
createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.TimestampsFilter
 
createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.ValueFilter
 
createFinishTableDescriptor(TableDescriptor) - Method in class org.apache.hadoop.hbase.regionserver.storefiletracker.ModifyColumnFamilyStoreFileTrackerProcedure
 
createFinishTableDescriptor(TableDescriptor) - Method in class org.apache.hadoop.hbase.regionserver.storefiletracker.ModifyStoreFileTrackerProcedure
 
createFinishTableDescriptor(TableDescriptor) - Method in class org.apache.hadoop.hbase.regionserver.storefiletracker.ModifyTableStoreFileTrackerProcedure
 
createFirstDeleteFamilyCellOnRow(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
Create a Delete Family Cell for the specified row and family that would be smaller than all other possible Delete Family KeyValues that have the same row and family.
createFirstKeyCell(ByteBuffer, int) - Method in class org.apache.hadoop.hbase.io.encoding.AbstractDataBlockEncoder
 
createFirstOnNextRow(Cell) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
 
createFirstOnRow(byte[]) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
Create a KeyValue that is smaller than all other possible KeyValues for the given row.
createFirstOnRow(byte[]) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
 
createFirstOnRow(byte[], byte[], byte[]) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
Create a KeyValue for the specified row, family and qualifier that would be smaller than all other possible KeyValues that have the same row,family,qualifier.
createFirstOnRow(byte[], byte[], byte[]) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
 
createFirstOnRow(byte[], byte[], byte[], byte[]) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
Create a KeyValue for the specified row, family and qualifier that would be smaller than all other possible KeyValues that have the same row, family, qualifier.
createFirstOnRow(byte[], byte[], byte[], long) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
Create a KeyValue for the specified row, family and qualifier that would be smaller than all other possible KeyValues that have the same row, family, qualifier.
createFirstOnRow(byte[], int, byte[], int, int, byte[], int, int, byte[], int, int) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
Create a KeyValue for the specified row, family and qualifier that would be smaller than all other possible KeyValues that have the same row, family, qualifier.
createFirstOnRow(byte[], int, int, byte[], int, int, byte[], int, int) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
Create a KeyValue for the specified row, family and qualifier that would be smaller than all other possible KeyValues that have the same row, family, qualifier.
createFirstOnRow(byte[], int, short) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
Create a KeyValue that is smaller than all other possible KeyValues for the given row.
createFirstOnRow(byte[], int, short) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
 
createFirstOnRow(byte[], int, short, byte[], int, byte, byte[], int, int) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
 
createFirstOnRow(byte[], long) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
Creates a KeyValue that is smaller than all other KeyValues that are older than the passed timestamp.
createFirstOnRow(Cell) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
Create a Cell that is smaller than all other possible Cells for the given Cell's row.
createFirstOnRowCol(Cell) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
 
createFirstOnRowCol(Cell, byte[], int, int) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
Create a Cell that is smaller than all other possible Cells for the given Cell's rk:cf and passed qualifier.
createFirstOnRowColTS(Cell, long) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
Creates the first cell with the row/family/qualifier of this cell and the given timestamp.
createFirstOnRowFamily(Cell, byte[], int, int) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
 
createFlushContext(long, FlushLifeCycleTracker) - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
createFlushWALEdit(RegionInfo, WALProtos.FlushDescriptor) - Static method in class org.apache.hadoop.hbase.wal.WALEdit
 
createForTesting(RegionInfo, RegionState.State) - Static method in class org.apache.hadoop.hbase.master.RegionState
 
createForWal(FileSystem, Path, boolean) - Static method in class org.apache.hadoop.hbase.util.CommonFSUtils
Attempt to use builder API via reflection to create a file with the given parameters and replication enabled.
createForWal(FileSystem, Path, boolean, int, short, long, boolean, boolean) - Static method in class org.apache.hadoop.hbase.util.CommonFSUtils
Attempt to use builder API via reflection to create a file with the given parameters and replication enabled.
createFromFileInfo(HFileInfo) - Static method in class org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoderImpl
 
createFromFileInfo(HFileInfo) - Static method in class org.apache.hadoop.hbase.io.hfile.HFileIndexBlockEncoderImpl
 
createFromHFileLink(Configuration, FileSystem, Path, String, boolean) - Static method in class org.apache.hadoop.hbase.io.HFileLink
Create a new HFileLink starting from a hfileLink name
createFromMeta(DataInput, HFile.Reader) - Static method in class org.apache.hadoop.hbase.util.BloomFilterFactory
Instantiates the correct Bloom filter class based on the version provided in the meta block data.
createFromMeta(DataInput, HFile.Reader, BloomFilterMetrics) - Static method in class org.apache.hadoop.hbase.util.BloomFilterFactory
 
createGeneralBloomAtWrite(Configuration, CacheConfig, BloomType, int, HFile.Writer) - Static method in class org.apache.hadoop.hbase.util.BloomFilterFactory
Creates a new general (Row or RowCol) Bloom filter at the time of HStoreFile writing.
createGroupKey(byte[][]) - Method in class org.apache.hadoop.hbase.mapred.GroupingTableMap
Create a key by concatenating multiple column values.
createGroupKey(byte[][]) - Method in class org.apache.hadoop.hbase.mapreduce.GroupingTableMapper
Create a key by concatenating multiple column values.
createGson() - Static method in class org.apache.hadoop.hbase.util.GsonUtil
Create a builder which is used to create a Gson instance.
createGsonWithDisableHtmlEscaping() - Static method in class org.apache.hadoop.hbase.util.GsonUtil
 
createHandler(Configuration, UserProvider) - Method in class org.apache.hadoop.hbase.thrift.ThriftServer
 
createHBaseProtosSnapshotDesc(SnapshotDescription) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
Convert from SnapshotDescription to SnapshotProtos.SnapshotDescription
createHDFSRegionDir(Configuration, RegionInfo, TableDescriptor) - Static method in class org.apache.hadoop.hbase.util.HBaseFsckRepair
Creates, flushes, and closes a new region.
createHFileCorruptionChecker(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
Deprecated.
 
createHFileLinkName(RegionInfo, String) - Static method in class org.apache.hadoop.hbase.io.HFileLink
Create a new HFileLink name
createHFileLinkName(TableName, String, String) - Static method in class org.apache.hadoop.hbase.io.HFileLink
Create a new HFileLink name
createHostAndPortStr(String, int) - Static method in class org.apache.hadoop.hbase.util.Addressing
Create a host-and-port string
createHRegion(Configuration, RegionInfo, FileSystem, Path, TableDescriptor) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
Create a region under the given table directory.
createHRegion(RegionInfo, Path, Configuration, TableDescriptor, WAL) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
 
createHRegion(RegionInfo, Path, Configuration, TableDescriptor, WAL, boolean) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
Convenience method creating new HRegions.
createHRegion(RegionInfo, Path, Configuration, TableDescriptor, WAL, boolean, RegionServerServices) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
Convenience method creating new HRegions.
createImmutableSegment(CellComparator) - Method in class org.apache.hadoop.hbase.regionserver.SegmentFactory
create empty immutable segment for initializations This ImmutableSegment is used as a place holder for snapshot in Memstore.
createImmutableSegment(MutableSegment, MemStoreSizing) - Method in class org.apache.hadoop.hbase.regionserver.SegmentFactory
 
createImmutableSegmentByCompaction(Configuration, CellComparator, MemStoreSegmentsIterator, int, CompactingMemStore.IndexType, MemStoreCompactionStrategy.Action) - Method in class org.apache.hadoop.hbase.regionserver.SegmentFactory
 
createImmutableSegmentByFlattening(CSLMImmutableSegment, CompactingMemStore.IndexType, MemStoreSizing, MemStoreCompactionStrategy.Action) - Method in class org.apache.hadoop.hbase.regionserver.SegmentFactory
 
createImmutableSegmentByMerge(Configuration, CellComparator, MemStoreSegmentsIterator, int, List<ImmutableSegment>, CompactingMemStore.IndexType, MemStoreCompactionStrategy.Action) - Method in class org.apache.hadoop.hbase.regionserver.SegmentFactory
 
createInetSocketAddressFromHostAndPortStr(String) - Static method in class org.apache.hadoop.hbase.util.Addressing
Create a socket address
createIO(MetricsIOWrapper) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceFactory
Create a MetricsIOSource from a MetricsIOWrapper.
createIO(MetricsIOWrapper) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceFactoryImpl
 
createKey() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
 
createKey() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
 
createKeyOnly(boolean) - Method in class org.apache.hadoop.hbase.KeyValue
Creates a new KeyValue that only contains the key portion (the value is set to be null).
createKeyValueFromInputStream(InputStream, boolean) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
Create a KeyValue reading from the raw InputStream.
createKeyValueFromKey(byte[]) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
Returns a KeyValue made of a byte array that holds the key-only part.
createKeyValueFromKey(byte[], int, int) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
Return a KeyValue made of a byte array that holds the key-only part.
createKeyValueFromKey(ByteBuffer) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
Return a KeyValue made of a byte buffer that holds the key-only part.
createLastOnRow(byte[]) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
Creates a KeyValue that is last on the specified row id.
createLastOnRow(byte[]) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
 
createLastOnRow(byte[], int, int, byte[], int, int, byte[], int, int) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
Create a KeyValue for the specified row, family and qualifier that would be larger than or equal to all other possible KeyValues that have the same row, family, qualifier.
createLastOnRow(Cell) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
Create a Cell that is larger than all other possible Cells for the given Cell's row.
createLastOnRowCol(Cell) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
Create a Cell that is larger than all other possible Cells for the given Cell's rk:cf:q.
createLease(String, int, LeaseListener) - Method in class org.apache.hadoop.hbase.regionserver.LeaseManager
Create a lease and insert it to the map of leases.
createList(int) - Method in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
 
createLockRetryCounterFactory(Configuration) - Static method in class org.apache.hadoop.hbase.util.HBaseFsck
Deprecated.
Returns A retry counter factory configured for retrying lock file creation.
createMasterThread(Configuration, Class<? extends HMaster>, int) - Static method in class org.apache.hadoop.hbase.util.JVMClusterUtil
Creates a JVMClusterUtil.MasterThread.
createMaxByteArray(int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Create a max byte array with the specified max byte count
createMemStoreCompactor(MemoryCompactionPolicy) - Method in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
 
createMetaTableDescriptorBuilder(Configuration) - Static method in class org.apache.hadoop.hbase.util.FSTableDescriptors
 
createMigrationTableDescriptor(Configuration, TableDescriptor) - Method in class org.apache.hadoop.hbase.regionserver.storefiletracker.ModifyColumnFamilyStoreFileTrackerProcedure
 
createMigrationTableDescriptor(Configuration, TableDescriptor) - Method in class org.apache.hadoop.hbase.regionserver.storefiletracker.ModifyStoreFileTrackerProcedure
 
createMigrationTableDescriptor(Configuration, TableDescriptor) - Method in class org.apache.hadoop.hbase.regionserver.storefiletracker.ModifyTableStoreFileTrackerProcedure
 
createMobRefCell(Cell, byte[], byte[]) - Static method in class org.apache.hadoop.hbase.mob.MobUtils
 
createMobRefCell(Cell, byte[], Tag) - Static method in class org.apache.hadoop.hbase.mob.MobUtils
Creates a mob reference KeyValue.
createMobRegionInfo(TableName) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
Creates a RegionInfo object for MOB data.
createMutableSegment(Configuration, CellComparator, MemStoreSizing) - Method in class org.apache.hadoop.hbase.regionserver.SegmentFactory
 
createNamespace(NamespaceDescriptor) - Method in interface org.apache.hadoop.hbase.client.Admin
Create a new namespace.
createNamespace(NamespaceDescriptor) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Create a new namespace.
createNamespace(NamespaceDescriptor, NonceKey, ProcedurePrepareLatch) - Method in interface org.apache.hadoop.hbase.master.ClusterSchema
Create a new Namespace.
createNamespace(RpcController, MasterProtos.CreateNamespaceRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
createNamespace(RpcController, MasterProtos.CreateNamespaceRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
 
createNamespaceAsync(NamespaceDescriptor) - Method in interface org.apache.hadoop.hbase.client.Admin
Create a new namespace.
createNamespaceAsync(NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
createNettyServerRpcConnection(Channel) - Method in class org.apache.hadoop.hbase.ipc.NettyRpcServer
 
createNextOnRowCol(Cell) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
Return a new cell is located following input cell.
createNInputSplitsUniform(InputSplit, int) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
Create n splits for one InputSplit, For now only support uniform distribution
createNodeIfNotExistsAndWatch(ZKWatcher, String, byte[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Creates the specified znode to be a persistent node carrying the specified data.
createNodeIfNotExistsNoWatch(ZKWatcher, String, byte[], CreateMode) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Creates the specified znode with the specified data but does not watch it.
createObject(K) - Method in interface org.apache.hadoop.hbase.util.ObjectPool.ObjectFactory
Creates a new shared object associated with the given key, identified by the equals method.
createOutput(FileSystem, Path, boolean, boolean, short, long, EventLoopGroup, Class<? extends Channel>, StreamSlowMonitor, boolean) - Static method in class org.apache.hadoop.hbase.io.asyncfs.AsyncFSOutputHelper
Create FanOutOneBlockAsyncDFSOutput for DistributedFileSystem, and a simple implementation for other FileSystem which wraps around a FSDataOutputStream.
createOutput(DistributedFileSystem, Path, boolean, boolean, short, long, EventLoopGroup, Class<? extends Channel>, StreamSlowMonitor, boolean) - Static method in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputHelper
Create a FanOutOneBlockAsyncDFSOutput.
createOutputStream(OutputStream) - Method in class org.apache.hadoop.hbase.io.compress.ReusableStreamGzipCodec
 
createOutputStream(Configuration, FileSystem, Path, InetSocketAddress[]) - Static method in class org.apache.hadoop.hbase.io.hfile.HFileWriterImpl
A helper method to create HFile output streams in constructors
createPath(TableName, String, String, String) - Static method in class org.apache.hadoop.hbase.io.HFileLink
Create an HFileLink relative path for the table/region/family/hfile location
createPlainCompressionStream(OutputStream, Compressor) - Method in enum org.apache.hadoop.hbase.io.compress.Compression.Algorithm
Creates a compression stream without any additional wrapping into buffering streams.
createPool() - Method in class org.apache.hadoop.hbase.util.PoolMap
 
createPriority() - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
 
createPriority() - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
 
createProcessor() - Method in class org.apache.hadoop.hbase.thrift.ThriftServer
 
createProtobufOutput() - Method in interface org.apache.hadoop.hbase.rest.ProtobufMessageHandler
Returns the protobuf represention of the model
createProtosSnapShotDescType(String) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
Creates SnapshotProtos.SnapshotDescription.Type from the type of SnapshotDescription string
createProtosSnapShotDescType(SnapshotType) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
Creates SnapshotProtos.SnapshotDescription.Type from SnapshotType
createReader(FileSystem, Path, Configuration) - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
Creates reader with cache configuration disabled
createReader(FileSystem, Path, CacheConfig, boolean, Configuration) - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
 
createReader(ReaderContext, CacheConfig) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
 
createReader(ReaderContext, HFileInfo, CacheConfig, Configuration) - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
Method returns the reader given the specified arguments.
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.HFileInputFormat
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableInputFormatBase
Builds a TableRecordReader.
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
Builds a TableRecordReader.
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormat
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.WALInputFormat
 
createRecoveredEditsWriter(FileSystem, Path) - Method in class org.apache.hadoop.hbase.wal.WALFactory
Should be package-private, visible for recovery testing.
createReference(K, V) - Method in class org.apache.hadoop.hbase.util.ObjectPool
Create a reference associated with the given object
createReference(K, V) - Method in class org.apache.hadoop.hbase.util.SoftObjectPool
 
createReference(K, V) - Method in class org.apache.hadoop.hbase.util.WeakObjectPool
 
createRegion(Configuration, Path, TableDescriptor, RegionInfo, ModifyRegionUtils.RegionFillTask) - Static method in class org.apache.hadoop.hbase.util.ModifyRegionUtils
Create new set of regions on the specified file-system.
createRegion(MetricsRegionWrapper) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceFactory
Create a MetricsRegionSource from a MetricsRegionWrapper.
createRegion(MetricsRegionWrapper) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceFactoryImpl
 
createRegionDir(Configuration, RegionInfo, Path) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
Create the region directory in the filesystem.
createRegionEventDescriptorQualifier(WALProtos.RegionEventDescriptor.EventType) - Static method in class org.apache.hadoop.hbase.wal.WALEdit
 
createRegionEventWALEdit(byte[], WALProtos.RegionEventDescriptor) - Static method in class org.apache.hadoop.hbase.wal.WALEdit
 
createRegionEventWALEdit(RegionInfo, WALProtos.RegionEventDescriptor) - Static method in class org.apache.hadoop.hbase.wal.WALEdit
 
createRegionInfos(TableDescriptor, byte[][]) - Static method in class org.apache.hadoop.hbase.util.ModifyRegionUtils
 
createRegionLoad(String) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
createRegionLoadStats(ClientProtos.RegionLoadStats) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
 
createRegionName(TableName, byte[], byte[], boolean) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
Make a region name of passed parameters.
createRegionName(TableName, byte[], byte[], boolean) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionInfo.createRegionName(TableName, byte[], byte[], boolean).
createRegionName(TableName, byte[], byte[], int, boolean) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
Make a region name of passed parameters.
createRegionName(TableName, byte[], byte[], int, boolean) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionInfo.createRegionName(TableName, byte[], byte[], int, boolean).
createRegionName(TableName, byte[], long, boolean) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
Make a region name of passed parameters.
createRegionName(TableName, byte[], long, boolean) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionInfo.createRegionName(TableName, byte[], long, boolean).
createRegionName(TableName, byte[], long, int, boolean) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
Make a region name of passed parameters.
createRegionName(TableName, byte[], long, int, boolean) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionInfo.createRegionName(TableName, byte[], long, int, boolean).
createRegionName(TableName, byte[], String, boolean) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
Make a region name of passed parameters.
createRegionName(TableName, byte[], String, boolean) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionInfo.createRegionName(TableName, byte[], String, boolean).
createRegionOnFileSystem(Configuration, FileSystem, Path, RegionInfo) - Static method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
Create a new Region on file-system.
createRegions(ThreadPoolExecutor, Configuration, Path, TableDescriptor, RegionInfo[], ModifyRegionUtils.RegionFillTask) - Static method in class org.apache.hadoop.hbase.util.ModifyRegionUtils
Create new set of regions on the specified file-system.
createRegions(Configuration, Path, TableDescriptor, RegionInfo[], ModifyRegionUtils.RegionFillTask) - Static method in class org.apache.hadoop.hbase.util.ModifyRegionUtils
Create new set of regions on the specified file-system.
createRegionServerStatusStub(boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
Get the current master from ZooKeeper and open the RPC connection to it.
createRegionServerThread(Configuration, Class<? extends HRegionServer>, int) - Static method in class org.apache.hadoop.hbase.util.JVMClusterUtil
Creates a JVMClusterUtil.RegionServerThread.
createRegionSizeCalculator(RegionLocator, Admin) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
 
createRegistryForMasterCoprocessor(String) - Static method in class org.apache.hadoop.hbase.coprocessor.MetricsCoprocessor
 
createRegistryForRegionCoprocessor(String) - Static method in class org.apache.hadoop.hbase.coprocessor.MetricsCoprocessor
 
createRegistryForRSCoprocessor(String) - Static method in class org.apache.hadoop.hbase.coprocessor.MetricsCoprocessor
 
createRegistryForWALCoprocessor(String) - Static method in class org.apache.hadoop.hbase.coprocessor.MetricsCoprocessor
 
createRegistryInfoForRegionCoprocessor(String) - Static method in class org.apache.hadoop.hbase.coprocessor.MetricsCoprocessor
 
createRegistryInfoForWALCoprocessor(String) - Static method in class org.apache.hadoop.hbase.coprocessor.MetricsCoprocessor
 
createReplicationMarkerEdit(byte[], long) - Static method in class org.apache.hadoop.hbase.wal.WALEdit
Creates a replication tracker edit with WALEdit.METAFAMILY family and WALEdit.REPLICATION_MARKER qualifier and has null value.
CreateRescanAsyncCallback() - Constructor for class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination.CreateRescanAsyncCallback
 
createResource(PoolMap.PoolResourceSupplier<V>) - Static method in class org.apache.hadoop.hbase.util.PoolMap
 
createRestoreTableDescriptor(TableDescriptor, String) - Method in class org.apache.hadoop.hbase.regionserver.storefiletracker.ModifyColumnFamilyStoreFileTrackerProcedure
 
createRestoreTableDescriptor(TableDescriptor, String) - Method in class org.apache.hadoop.hbase.regionserver.storefiletracker.ModifyStoreFileTrackerProcedure
 
createRestoreTableDescriptor(TableDescriptor, String) - Method in class org.apache.hadoop.hbase.regionserver.storefiletracker.ModifyTableStoreFileTrackerProcedure
 
createRootDir(boolean) - Method in class org.apache.hadoop.hbase.testing.TestingHBaseClusterOption.Builder
 
createRpcChannel(ServerName, User, int) - Method in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
 
createRpcChannel(ServerName, User, int) - Method in interface org.apache.hadoop.hbase.ipc.RpcClient
Creates a "channel" that can be used by a protobuf service.
createRpcServer(Server, String, List<RpcServer.BlockingServiceAndInterface>, InetSocketAddress, Configuration, RpcScheduler) - Static method in class org.apache.hadoop.hbase.ipc.RpcServerFactory
 
createRpcServer(Server, String, List<RpcServer.BlockingServiceAndInterface>, InetSocketAddress, Configuration, RpcScheduler, boolean) - Static method in class org.apache.hadoop.hbase.ipc.RpcServerFactory
 
createRpcServer(Server, RpcSchedulerFactory, InetSocketAddress, String) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
 
createRpcServer(Server, RpcSchedulerFactory, InetSocketAddress, String) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
 
createRpcServices() - Method in class org.apache.hadoop.hbase.master.HMaster
 
createRpcServices() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
createScanFromConfiguration(Configuration) - Static method in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
Sets up a Scan instance, applying settings from the configuration property constants defined in TableInputFormat.
createScanFromCursor(Cursor) - Static method in class org.apache.hadoop.hbase.client.Scan
Create a new Scan with a cursor.
createScanner(List<KeyValueScanner>, FlushLifeCycleTracker) - Method in class org.apache.hadoop.hbase.regionserver.DefaultStoreFlusher
Creates the scanner for flushing snapshot.
createScanner(Scan, ScanInfo, NavigableSet<byte[]>, long) - Method in class org.apache.hadoop.hbase.regionserver.HMobStore
Gets the MobStoreScanner or MobReversedStoreScanner.
createScanner(Scan, ScanInfo, NavigableSet<byte[]>, long) - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
createScannerCallable() - Method in class org.apache.hadoop.hbase.client.ClientScanner
Will be called in moveToNextRegion to create ScannerCallable.
createScannerCallable() - Method in class org.apache.hadoop.hbase.client.ClientSimpleScanner
 
createScannerCallable() - Method in class org.apache.hadoop.hbase.client.ReversedClientScanner
 
createScanResultCache(Scan) - Static method in class org.apache.hadoop.hbase.client.ConnectionUtils
 
createSecretManager() - Method in class org.apache.hadoop.hbase.ipc.RpcServer
 
createSeeker() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileIndexBlockEncoder
 
createSeeker() - Method in class org.apache.hadoop.hbase.io.hfile.HFileIndexBlockEncoderImpl
 
createSeeker() - Method in class org.apache.hadoop.hbase.io.hfile.NoOpIndexBlockEncoder
 
createSeeker(HFileBlockDecodingContext) - Method in class org.apache.hadoop.hbase.io.encoding.CopyKeyDataBlockEncoder
 
createSeeker(HFileBlockDecodingContext) - Method in interface org.apache.hadoop.hbase.io.encoding.DataBlockEncoder
Create a HFileBlock seeker which find KeyValues within a block.
createSeeker(HFileBlockDecodingContext) - Method in class org.apache.hadoop.hbase.io.encoding.DiffKeyDeltaEncoder
 
createSeeker(HFileBlockDecodingContext) - Method in class org.apache.hadoop.hbase.io.encoding.FastDiffDeltaEncoder
 
createSeeker(HFileBlockDecodingContext) - Method in class org.apache.hadoop.hbase.io.encoding.PrefixKeyDeltaEncoder
 
createSeeker(HFileBlockDecodingContext) - Method in class org.apache.hadoop.hbase.io.encoding.RowIndexCodecV1
 
createServer(MetricsRegionServerWrapper) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceFactory
Given a wrapper create a MetricsRegionServerSource.
createServer(MetricsRegionServerWrapper) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceFactoryImpl
 
createServerManager(MasterServices, RegionServerList) - Method in class org.apache.hadoop.hbase.master.HMaster
Create a ServerManager instance.
createServerSocket(int) - Method in class org.apache.hadoop.hbase.SslRMIServerSocketFactorySecure
 
createSetData(ZKWatcher, String, byte[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Set data into node creating node if it doesn't yet exist.
createShortCircuitConnection(Configuration, User, ServerName, AdminProtos.AdminService.BlockingInterface, ClientProtos.ClientService.BlockingInterface, ConnectionRegistry) - Static method in class org.apache.hadoop.hbase.client.ServerConnectionUtils
Creates a short-circuit connection that can bypass the RPC layer (serialization, deserialization, networking, etc..) when talking to a local server.
org.apache.hadoop.hbase.snapshot.CreateSnapshot - Class in org.apache.hadoop.hbase.snapshot
This is a command line class that will snapshot a given table.
CreateSnapshot() - Constructor for class org.apache.hadoop.hbase.snapshot.CreateSnapshot
 
createSnapshotDesc(SnapshotProtos.SnapshotDescription) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
Convert from SnapshotProtos.SnapshotDescription to SnapshotDescription
createSnapshotType(SnapshotProtos.SnapshotDescription.Type) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
Creates SnapshotType from the SnapshotProtos.SnapshotDescription.Type
createSocket(String, int) - Method in class org.apache.hadoop.hbase.SslRMIClientSocketFactorySecure
 
createSplitsDir(RegionInfo, RegionInfo) - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
Creates region split daughter directories under the table dir.
createSslContextForClient(Configuration) - Static method in class org.apache.hadoop.hbase.io.crypto.tls.X509Util
 
createSslContextForServer(Configuration) - Static method in class org.apache.hadoop.hbase.io.crypto.tls.X509Util
 
createStartKeyFromRow(byte[], ScanInfo) - Static method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher
 
createStore() - Method in class org.apache.hadoop.hbase.quotas.RegionSizeStoreFactory
 
createStoreConfiguration(Configuration, TableDescriptor, ColumnFamilyDescriptor) - Static method in class org.apache.hadoop.hbase.regionserver.StoreUtils
 
createStoreEngine(HStore, Configuration, CellComparator) - Method in class org.apache.hadoop.hbase.regionserver.HMobStore
Creates the mob store engine.
createStoreEngine(HStore, Configuration, CellComparator) - Method in class org.apache.hadoop.hbase.regionserver.HStore
Creates the store engine configured for the given Store.
createStoreFileAndReader(Path) - Method in class org.apache.hadoop.hbase.regionserver.StoreEngine
 
createStoreFileAndReader(StoreFileInfo) - Method in class org.apache.hadoop.hbase.regionserver.StoreEngine
 
org.apache.hadoop.hbase.regionserver.CreateStoreFileWriterParams - Class in org.apache.hadoop.hbase.regionserver
 
createStoreFlusher(Configuration, HStore) - Method in class org.apache.hadoop.hbase.mob.MobStoreEngine
 
createStoreFlusher(Configuration, HStore) - Method in class org.apache.hadoop.hbase.regionserver.DefaultStoreEngine
 
createStreamReader(FileSystem, Path) - Method in class org.apache.hadoop.hbase.wal.WALFactory
 
createStreamReader(FileSystem, Path, Configuration) - Static method in class org.apache.hadoop.hbase.wal.WALFactory
Create a one-way stream reader for a given path.
createStreamReader(FileSystem, Path, Configuration, long) - Static method in class org.apache.hadoop.hbase.wal.WALFactory
Create a one-way stream reader for a given path.
createStreamReader(FileSystem, Path, CancelableProgressable) - Method in class org.apache.hadoop.hbase.wal.WALFactory
Create a one-way stream reader for the WAL.
createStreamReader(FileSystem, Path, CancelableProgressable, long) - Method in class org.apache.hadoop.hbase.wal.WALFactory
Create a one-way stream reader for the WAL, and start reading from the given startPosition.
createSubCellFlatMap(int, int, boolean) - Method in class org.apache.hadoop.hbase.regionserver.CellArrayMap
 
createSubCellFlatMap(int, int, boolean) - Method in class org.apache.hadoop.hbase.regionserver.CellChunkMap
 
createSubCellFlatMap(int, int, boolean) - Method in class org.apache.hadoop.hbase.regionserver.CellFlatMap
 
createSubmittableJob(String[]) - Method in class org.apache.hadoop.hbase.mapred.RowCounter
Returns the JobConf
createSubmittableJob(String[]) - Method in class org.apache.hadoop.hbase.mapreduce.CopyTable
Sets up the actual job.
createSubmittableJob(String[]) - Method in class org.apache.hadoop.hbase.mapreduce.HashTable
 
createSubmittableJob(String[]) - Method in class org.apache.hadoop.hbase.mapreduce.SyncTable
 
createSubmittableJob(String[]) - Method in class org.apache.hadoop.hbase.mapreduce.WALPlayer
Sets up the actual job.
createSubmittableJob(Configuration) - Method in class org.apache.hadoop.hbase.mapreduce.RowCounter
Sets up the actual job.
createSubmittableJob(Configuration, String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.CellCounter
Sets up the actual job.
createSubmittableJob(Configuration, String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.Export
Sets up the actual job.
createSubmittableJob(Configuration, String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.Import
Sets up the actual job.
createSubmittableJob(Configuration, String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.ImportTsv
Sets up the actual job.
createSubmittableJob(Configuration, String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.RowCounter
Deprecated.
as of release 2.3.0. Will be removed on 4.0.0. Please use main method instead.
createSystemTable(TableDescriptor) - Method in class org.apache.hadoop.hbase.master.HMaster
 
createSystemTable(TableDescriptor) - Method in interface org.apache.hadoop.hbase.master.MasterServices
Create a system table using the given table definition.
createTable(String, MetricsTableWrapperAggregate) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceFactory
Create a MetricsTableSource from a MetricsTableWrapper.
createTable(String, MetricsTableWrapperAggregate) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceFactoryImpl
 
createTable(ByteBuffer, List<ColumnDescriptor>) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
 
createTable(TableDescriptor) - Method in interface org.apache.hadoop.hbase.client.Admin
Creates a new table.
createTable(TableDescriptor) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Creates a new table.
createTable(TableDescriptor, byte[][]) - Method in interface org.apache.hadoop.hbase.client.Admin
Creates a new table with an initial set of empty regions defined by the specified split keys.
createTable(TableDescriptor, byte[][]) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Creates a new table with an initial set of empty regions defined by the specified split keys.
createTable(TableDescriptor, byte[][], long, long) - Method in class org.apache.hadoop.hbase.master.HMaster
 
createTable(TableDescriptor, byte[][], long, long) - Method in interface org.apache.hadoop.hbase.master.MasterServices
Create a table using the given table definition.
createTable(TableDescriptor, byte[], byte[], int) - Method in interface org.apache.hadoop.hbase.client.Admin
Creates a new table with the specified number of regions.
createTable(TableDescriptor, byte[], byte[], int) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Creates a new table with the specified number of regions.
createTable(TableDescriptor, byte[], byte[], int) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
createTable(RpcController, MasterProtos.CreateTableRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
createTable(RpcController, MasterProtos.CreateTableRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
 
createTableAsync(TableDescriptor) - Method in interface org.apache.hadoop.hbase.client.Admin
Creates a new table but does not block and wait for it to come online.
createTableAsync(TableDescriptor) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
createTableAsync(TableDescriptor, byte[][]) - Method in interface org.apache.hadoop.hbase.client.Admin
Creates a new table but does not block and wait for it to come online.
createTableAsync(TableDescriptor, byte[][]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
createTableDescriptor(TableDescriptor) - Method in class org.apache.hadoop.hbase.util.FSTableDescriptors
Create new TableDescriptor in HDFS.
createTableDescriptor(TableDescriptor, boolean) - Method in class org.apache.hadoop.hbase.util.FSTableDescriptors
Create new TableDescriptor in HDFS.
createTableDescriptorForTableDirectory(FileSystem, Path, TableDescriptor, boolean) - Static method in class org.apache.hadoop.hbase.util.FSTableDescriptors
Create a new TableDescriptor in HDFS in the specified table directory.
createTableDescriptorForTableDirectory(Path, TableDescriptor, boolean) - Method in class org.apache.hadoop.hbase.util.FSTableDescriptors
Create a new TableDescriptor in HDFS in the specified table directory.
createTailingReader(FileSystem, Path, Configuration, long) - Static method in class org.apache.hadoop.hbase.wal.WALFactory
Create a tailing reader for the given path.
createTempName() - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
Generate a unique temporary Path.
createTempName(String) - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
Generate a unique temporary Path.
createThriftMetrics(Configuration) - Method in class org.apache.hadoop.hbase.thrift.ThriftServer
 
createThriftOneSource() - Method in interface org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceFactory
Create a Source for a thrift one server
createThriftOneSource() - Method in class org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceFactoryImpl
 
createThriftTwoSource() - Method in interface org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceFactory
Create a Source for a thrift two server
createThriftTwoSource() - Method in class org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceFactoryImpl
 
createTopReference(byte[]) - Static method in class org.apache.hadoop.hbase.io.Reference
Returns A Reference that points at top half of a an hfile
createTreeSet() - Method in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
 
createTServlet(TProtocolFactory) - Method in class org.apache.hadoop.hbase.thrift.ThriftServer
Create a Servlet for the http server
createUnescapdArgument(byte[], int, int) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
Removes the single quote escaping a single quote - thus it returns an unescaped argument
createUser(String) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceFactory
Create a MetricsUserSource from a user
createUser(String) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceFactoryImpl
 
createUserForTesting(Configuration, String, String[]) - Static method in class org.apache.hadoop.hbase.security.User
Generates a new User instance specifically for use in test code.
createUserForTesting(Configuration, String, String[]) - Static method in class org.apache.hadoop.hbase.security.User.SecureHadoopUser
Create a user for testing.
createValue() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
 
createValue() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
 
createVisibilityExpTags(String) - Method in class org.apache.hadoop.hbase.mapreduce.DefaultVisibilityExpressionResolver
 
createVisibilityExpTags(String) - Method in interface org.apache.hadoop.hbase.mapreduce.VisibilityExpressionResolver
Convert visibility expression into tags to be serialized.
createWAL() - Method in class org.apache.hadoop.hbase.wal.AbstractFSWALProvider
 
createWAL() - Method in class org.apache.hadoop.hbase.wal.AsyncFSWALProvider
 
createWAL() - Method in class org.apache.hadoop.hbase.wal.FSHLogProvider
 
createWALDir(boolean) - Method in class org.apache.hadoop.hbase.testing.TestingHBaseClusterOption.Builder
 
createWALWriter(FileSystem, Path) - Method in class org.apache.hadoop.hbase.wal.WALFactory
Create a writer for the WAL.
createWALWriter(FileSystem, Path, Configuration) - Static method in class org.apache.hadoop.hbase.wal.WALFactory
If you already have a WALFactory, you should favor the instance method.
createWithoutViolation(RegionServerServices, TableName, SpaceQuotaSnapshot) - Method in class org.apache.hadoop.hbase.quotas.SpaceViolationPolicyEnforcementFactory
Creates the "default" SpaceViolationPolicyEnforcement for a table that isn't in violation.
createWithParents(ZKWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Creates the specified node and all parent nodes required for it to exist.
createWithParents(ZKWatcher, String, byte[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Creates the specified node and all parent nodes required for it to exist.
createWriter() - Method in interface org.apache.hadoop.hbase.regionserver.AbstractMultiFileWriter.WriterFactory
 
createWriter() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFlusher.BoundaryStripeFlushRequest
 
createWriter() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFlusher.SizeStripeFlushRequest
 
createWriter() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFlusher.StripeFlushRequest
 
createWriter(Date, long, Compression.Algorithm, byte[], boolean, Consumer<Path>) - Method in class org.apache.hadoop.hbase.regionserver.HMobStore
Creates the writer for the mob file in the mob family directory.
createWriter(Configuration, FileSystem, Path, boolean) - Static method in class org.apache.hadoop.hbase.wal.FSHLogProvider
Public because of FSHLog.
createWriter(Configuration, FileSystem, Path, boolean, long) - Static method in class org.apache.hadoop.hbase.wal.FSHLogProvider
Public because of FSHLog.
createWriter(Configuration, FileSystem, ColumnFamilyDescriptor, String, Path, long, Compression.Algorithm, String, CacheConfig, Encryption.Context, boolean, String) - Static method in class org.apache.hadoop.hbase.mob.MobUtils
Creates a writer for the mob file in temp directory.
createWriter(Configuration, FileSystem, ColumnFamilyDescriptor, Path, long, Compression.Algorithm, CacheConfig, Encryption.Context, ChecksumType, int, int, BloomType, boolean) - Static method in class org.apache.hadoop.hbase.mob.MobUtils
Creates a writer for the mob file in temp directory.
createWriter(Configuration, FileSystem, ColumnFamilyDescriptor, Path, long, Compression.Algorithm, CacheConfig, Encryption.Context, ChecksumType, int, int, BloomType, boolean, Consumer<Path>) - Static method in class org.apache.hadoop.hbase.mob.MobUtils
Creates a writer for the mob file in temp directory.
createWriter(Configuration, FileSystem, ColumnFamilyDescriptor, MobFileName, Path, long, Compression.Algorithm, CacheConfig, Encryption.Context, boolean) - Static method in class org.apache.hadoop.hbase.mob.MobUtils
Creates a writer for the mob file in temp directory.
createWriter(Path) - Method in class org.apache.hadoop.hbase.wal.WALSplitter
Create a new WALProvider.Writer for writing log splits.
createWriter(CreateStoreFileWriterParams) - Method in class org.apache.hadoop.hbase.regionserver.StoreEngine
Create a writer for writing new store files.
createWriter(CreateStoreFileWriterParams) - Method in interface org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileTracker
Create a writer for writing new store files.
createWriter(MemStoreSnapshot, boolean, Consumer<Path>) - Method in class org.apache.hadoop.hbase.regionserver.DefaultStoreFlusher
 
createWriterInstance(Path) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
 
createWriterInstance(Path) - Method in class org.apache.hadoop.hbase.regionserver.wal.AsyncFSWAL
 
createWriterInstance(Path) - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
This method allows subclasses to inject different writers without having to extend other methods like rollWriter().
createWriterInTmp(String, Path, long, Compression.Algorithm, byte[], boolean, Consumer<Path>) - Method in class org.apache.hadoop.hbase.regionserver.HMobStore
Creates the writer for the mob file in temp directory.
createWriterInTmp(Date, long, Compression.Algorithm, byte[], boolean) - Method in class org.apache.hadoop.hbase.regionserver.HMobStore
Creates the writer for the mob file in temp directory.
createWriterInTmp(MobFileName, Path, long, Compression.Algorithm, boolean, Consumer<Path>) - Method in class org.apache.hadoop.hbase.regionserver.HMobStore
Creates the writer for the mob file in temp directory.
createWriterWithStoragePolicy(String) - Method in interface org.apache.hadoop.hbase.regionserver.AbstractMultiFileWriter.WriterFactory
 
createZNode(String, byte[]) - Method in class org.apache.hadoop.hbase.chaos.ChaosAgent
Function to create PERSISTENT ZNODE with given path and data given as params
CREDENTIALS_LOCATION - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv
 
CRLF - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
CRYPTO_ALTERNATE_KEY_ALGORITHM_CONF_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
Configuration key for the name of the alternate cipher algorithm for the cluster, a string
CRYPTO_CIPHERPROVIDER_CONF_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
Configuration key for the crypto algorithm provider, a class name
CRYPTO_ENABLED_CONF_DEFAULT - Static variable in class org.apache.hadoop.hbase.io.crypto.Encryption
Default value for globally enable / disable column family encryption (set to "true" for backward compatibility)
CRYPTO_ENABLED_CONF_KEY - Static variable in class org.apache.hadoop.hbase.io.crypto.Encryption
Configuration key for globally enable / disable column family encryption
CRYPTO_KEY_ALGORITHM_CONF_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
Configuration key for the algorithm used for creating jks key, a string
CRYPTO_KEY_FAIL_ON_ALGORITHM_MISMATCH_CONF_DEFAULT - Static variable in class org.apache.hadoop.hbase.io.crypto.Encryption
Default behaviour is not to fail if the hash algorithm configured differs from the one used in the HFile.
CRYPTO_KEY_FAIL_ON_ALGORITHM_MISMATCH_CONF_KEY - Static variable in class org.apache.hadoop.hbase.io.crypto.Encryption
Configuration key for specifying the behaviour if the configured hash algorithm differs from the one used for generating key hash in encrypted HFiles currently being read.
CRYPTO_KEY_HASH_ALGORITHM_CONF_DEFAULT - Static variable in class org.apache.hadoop.hbase.io.crypto.Encryption
Default hash algorithm used for generating key hash in encrypted HFiles.
CRYPTO_KEY_HASH_ALGORITHM_CONF_KEY - Static variable in class org.apache.hadoop.hbase.io.crypto.Encryption
Configuration key for the hash algorithm used for generating key hash in encrypted HFiles.
CRYPTO_KEYPROVIDER_CONF_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
Configuration key for the crypto key provider, a class name
CRYPTO_KEYPROVIDER_PARAMETERS_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
Configuration key for the crypto key provider parameters
CRYPTO_MASTERKEY_ALTERNATE_NAME_CONF_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
Configuration key for the name of the alternate master key for the cluster, a string
CRYPTO_MASTERKEY_NAME_CONF_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
Configuration key for the name of the master key for the cluster, a string
CRYPTO_WAL_ALGORITHM_CONF_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
Configuration key for the algorithm to use when encrypting the WAL, a string
CRYPTO_WAL_KEY_NAME_CONF_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
Configuration key for the name of the master WAL encryption key for the cluster, a string
org.apache.hadoop.hbase.io.crypto.aes.CryptoAES - Class in org.apache.hadoop.hbase.io.crypto.aes
AES encryption and decryption.
CryptoAES(String, Properties, byte[], byte[], byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.io.crypto.aes.CryptoAES
 
org.apache.hadoop.hbase.io.crypto.CryptoCipherProvider - Class in org.apache.hadoop.hbase.io.crypto
The default cipher provider.
CRYPTOSTREAM_BUFFERSIZE_KEY - Static variable in class org.apache.hadoop.hbase.io.crypto.aes.CommonsCryptoAES
 
CSLM_MAP - Enum constant in enum org.apache.hadoop.hbase.regionserver.CompactingMemStore.IndexType
 
org.apache.hadoop.hbase.regionserver.CSLMImmutableSegment - Class in org.apache.hadoop.hbase.regionserver
CSLMImmutableSegment is an abstract class that extends the API supported by a Segment, and ImmutableSegment.
CSLMImmutableSegment(Segment, MemStoreSizing) - Constructor for class org.apache.hadoop.hbase.regionserver.CSLMImmutableSegment
------------------------------------------------------------------------ Copy C-tor to be used when new CSLMImmutableSegment is being built from a Mutable one.
ctx - Variable in class org.apache.hadoop.hbase.replication.BaseReplicationEndpoint
 
cur_worker_name - Variable in class org.apache.hadoop.hbase.master.SplitLogManager.Task
Deprecated.
 
curBlock - Variable in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
 
curBuf - Variable in class org.apache.hadoop.hbase.io.ByteBufferOutputStream
 
CurCall - Static variable in class org.apache.hadoop.hbase.ipc.RpcServer
This is set to Call object before Handler invokes an RPC and ybdie after the call returns.
current - Variable in class org.apache.hadoop.hbase.codec.KeyValueCodec.ByteBuffKeyValueDecoder
 
current - Variable in class org.apache.hadoop.hbase.regionserver.KeyValueHeap
The current sub-scanner, i.e.
current - Variable in class org.apache.hadoop.hbase.regionserver.SegmentScanner
 
current() - Method in interface org.apache.hadoop.hbase.CellScanner
Returns the current Cell which may be mutable
current() - Method in class org.apache.hadoop.hbase.client.Result
 
current() - Method in class org.apache.hadoop.hbase.codec.BaseDecoder
 
current() - Method in class org.apache.hadoop.hbase.codec.KeyValueCodec.ByteBuffKeyValueDecoder
 
CURRENT_VERSION - Static variable in class org.apache.hadoop.hbase.ipc.RpcServer
 
currentClientHasMinimumVersion(int, int) - Static method in class org.apache.hadoop.hbase.client.VersionInfoUtil
 
currentComponent - Variable in class org.apache.hadoop.hbase.util.ConcatenatedLists.Iterator
 
org.apache.hadoop.hbase.tool.coprocessor.CurrentCoprocessorMethods - Class in org.apache.hadoop.hbase.tool.coprocessor
 
CurrentCoprocessorMethods() - Constructor for class org.apache.hadoop.hbase.tool.coprocessor.CurrentCoprocessorMethods
 
currentQueueLimit - Variable in class org.apache.hadoop.hbase.ipc.RpcExecutor
 
currentRegion - Variable in class org.apache.hadoop.hbase.client.ClientScanner
 
currentRow - Variable in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher
Row the query is on
currentRow() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher
Returns a cell represent the current row
currentTime() - Method in class org.apache.hadoop.hbase.util.DefaultEnvironmentEdge
Returns the currentTime.
currentTime() - Method in interface org.apache.hadoop.hbase.util.EnvironmentEdge
Returns the currentTime.
currentTime() - Static method in class org.apache.hadoop.hbase.util.EnvironmentEdgeManager
Defers to the delegate and calls the EnvironmentEdge.currentTime() method.
currentTime() - Method in class org.apache.hadoop.hbase.util.IncrementingEnvironmentEdge
Returns the currentTime.
currentTime() - Method in class org.apache.hadoop.hbase.util.ManualEnvironmentEdge
 
cursor - Variable in class org.apache.hadoop.hbase.client.ScannerCallable
 
cursor() - Method in interface org.apache.hadoop.hbase.client.AdvancedScanResultConsumer.ScanController
Get the scan cursor if available.
cursor(boolean) - Static method in class org.apache.hadoop.hbase.hbtop.terminal.impl.EscapeSequences
 
org.apache.hadoop.hbase.client.Cursor - Class in org.apache.hadoop.hbase.client
Scan cursor to tell client where server is scanning Scan.setNeedCursorResult(boolean) Result.isCursor() Result.getCursor()
org.apache.hadoop.hbase.hbtop.terminal.CursorPosition - Class in org.apache.hadoop.hbase.hbtop.terminal
A 2-d position in 'terminal space'.
CursorPosition(int, int) - Constructor for class org.apache.hadoop.hbase.hbtop.terminal.CursorPosition
 
CUSTOM_CALLER_CONF_KEY - Static variable in class org.apache.hadoop.hbase.client.RpcRetryingCallerFactory
Configuration key for a custom RpcRetryingCaller
CUSTOM_CONTROLLER_CONF_KEY - Static variable in class org.apache.hadoop.hbase.ipc.RpcControllerFactory
Custom RPC Controller factory allows frameworks to change the RPC controller.
CUSTOM_FILTERS - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
CUSTOM_RPC_CLIENT_IMPL_CONF_KEY - Static variable in class org.apache.hadoop.hbase.ipc.RpcClientFactory
 
CUSTOM_RPC_SERVER_IMPL_CONF_KEY - Static variable in class org.apache.hadoop.hbase.ipc.RpcServerFactory
 
CUSTOM_TAG_TYPE_RANGE - Static variable in interface org.apache.hadoop.hbase.Tag
Custom tags if created are suggested to be above this range.
org.apache.hadoop.hbase.regionserver.CustomizedScanInfoBuilder - Class in org.apache.hadoop.hbase.regionserver
Helper class for CP hooks to change max versions and TTL.
CustomizedScanInfoBuilder(ScanInfo) - Constructor for class org.apache.hadoop.hbase.regionserver.CustomizedScanInfoBuilder
 
CustomizedScanInfoBuilder(ScanInfo, Scan) - Constructor for class org.apache.hadoop.hbase.regionserver.CustomizedScanInfoBuilder
 
CYAN - Enum constant in enum org.apache.hadoop.hbase.hbtop.terminal.Color
 

D

D - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for 'D'
org.apache.hadoop.hbase.DaemonThreadFactory - Class in org.apache.hadoop.hbase
Thread factory that creates daemon threads
DaemonThreadFactory(String) - Constructor for class org.apache.hadoop.hbase.DaemonThreadFactory
 
DAILY - Enum constant in enum org.apache.hadoop.hbase.client.MobCompactPartitionPolicy
Compact daily mob files into one file
org.apache.hadoop.hbase.regionserver.wal.DamagedWALException - Exception in org.apache.hadoop.hbase.regionserver.wal
Thrown when a failed append or sync on a WAL.
DamagedWALException() - Constructor for exception org.apache.hadoop.hbase.regionserver.wal.DamagedWALException
 
DamagedWALException(String) - Constructor for exception org.apache.hadoop.hbase.regionserver.wal.DamagedWALException
 
DamagedWALException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.regionserver.wal.DamagedWALException
 
DamagedWALException(Throwable) - Constructor for exception org.apache.hadoop.hbase.regionserver.wal.DamagedWALException
 
data - Variable in class org.apache.hadoop.hbase.regionserver.Chunk
Actual underlying data
DATA - Enum constant in enum org.apache.hadoop.hbase.io.hfile.BlockType.BlockCategory
 
DATA - Enum constant in enum org.apache.hadoop.hbase.io.hfile.BlockType
Data block, both versions
DATA_BLOCK_ENCODING - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
DATA_BLOCK_ENCODING - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
DATA_BLOCK_ENCODING - Static variable in interface org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoder
Type of encoding used for data blocks in HFile.
DATA_CHUNK - Enum constant in enum org.apache.hadoop.hbase.regionserver.ChunkCreator.ChunkType
 
DATA_FILE_UMASK_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
File permission umask to use when creating hbase data files
DATA_MANIFEST_NAME - Static variable in class org.apache.hadoop.hbase.snapshot.SnapshotManifest
 
DATA_SIZE_WITHOUT_WAL - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
DATA_SIZE_WITHOUT_WAL_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
DATABLOCK_ENCODING_OVERRIDE_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
 
DATABLOCK_READ_COUNT - Static variable in class org.apache.hadoop.hbase.io.hfile.HFile
 
dataBlockEncoder - Variable in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
What kind of data block encoding should be used while reading, writing, and handling cache.
org.apache.hadoop.hbase.io.encoding.DataBlockEncoder - Interface in org.apache.hadoop.hbase.io.encoding
Encoding of KeyValue.
org.apache.hadoop.hbase.io.encoding.DataBlockEncoder.EncodedSeeker - Interface in org.apache.hadoop.hbase.io.encoding
An interface which enable to seek while underlying data is encoded.
org.apache.hadoop.hbase.io.encoding.DataBlockEncoding - Enum in org.apache.hadoop.hbase.io.encoding
Provide access to all data block encoding algorithms.
dataBlockIndexReader - Variable in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
Data block index reader keeping the root data index in memory
DATANODE_SLOW_PACKET_PROCESS_TIME_KEY - Static variable in class org.apache.hadoop.hbase.io.asyncfs.monitor.StreamSlowMonitor
Configure for the slow packet process time, a duration from send to ACK.
dataNodeHosts(String[]) - Method in class org.apache.hadoop.hbase.testing.TestingHBaseClusterOption.Builder
 
org.apache.hadoop.hbase.types.DataType<T> - Interface in org.apache.hadoop.hbase.types
DataType is the base class for all HBase data types.
org.apache.hadoop.hbase.regionserver.DateTieredMultiFileWriter - Class in org.apache.hadoop.hbase.regionserver
class for cell sink that separates the provided cells into multiple files for date tiered compaction.
DateTieredMultiFileWriter(List<Long>, Map<Long, String>, boolean) - Constructor for class org.apache.hadoop.hbase.regionserver.DateTieredMultiFileWriter
 
org.apache.hadoop.hbase.regionserver.DateTieredStoreEngine - Class in org.apache.hadoop.hbase.regionserver
HBASE-15400 This store engine allows us to store data in date tiered layout with exponential sizing so that the more recent data has more granularity.
DateTieredStoreEngine() - Constructor for class org.apache.hadoop.hbase.regionserver.DateTieredStoreEngine
 
DAY_IN_SECONDS - Static variable in class org.apache.hadoop.hbase.HConstants
Seconds in a day, hour and minute
DEAD - Enum constant in enum org.apache.hadoop.hbase.master.ServerManager.ServerLiveState
 
DEAD_REGION_SERVERS_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
 
DEAD_REGION_SERVERS_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
 
DEAD_SERVER_OPEN_REGIONS - Static variable in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
 
DEAD_SERVERS - Enum constant in enum org.apache.hadoop.hbase.ClusterMetrics.Option
metrics about dead region servers
deadline - Variable in class org.apache.hadoop.hbase.ipc.ServerCall
 
org.apache.hadoop.hbase.master.DeadServer - Class in org.apache.hadoop.hbase.master
Class to hold dead servers list and utility querying dead server list.
DeadServer() - Constructor for class org.apache.hadoop.hbase.master.DeadServer
 
deallocate() - Method in class org.apache.hadoop.hbase.nio.RefCnt
 
org.apache.hadoop.hbase.io.DeallocateRewriteByteBuffAllocator - Class in org.apache.hadoop.hbase.io
A ByteBuffAllocator that rewrite the bytebuffers right after released.
debug() - Method in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
 
debugLsr(Configuration, Path) - Static method in class org.apache.hadoop.hbase.util.HBaseFsck
Deprecated.
ls -r for debugging purposes
debugLsr(Configuration, Path, HbckErrorReporter) - Static method in class org.apache.hadoop.hbase.util.HBaseFsck
Deprecated.
ls -r for debugging purposes
DEC_BLOCKCACHE_TUNING_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSource
 
DEC_BLOCKCACHE_TUNING_NAME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSource
 
DEC_MEMSTORE_TUNING_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSource
 
DEC_MEMSTORE_TUNING_NAME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSource
 
decActiveWorkerCount() - Method in interface org.apache.hadoop.hbase.thrift.MetricsThriftServerSource
Decrement number of active thrift workers.
decActiveWorkerCount() - Method in class org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceImpl
 
decActiveWorkerCount() - Method in class org.apache.hadoop.hbase.thrift.ThriftMetrics
 
decGauge(String, long) - Method in interface org.apache.hadoop.hbase.metrics.BaseSource
Subtract some amount from a gauge.
decGauge(String, long) - Method in class org.apache.hadoop.hbase.metrics.BaseSourceImpl
Decrease the value of a named gauge.
decGlobalMemStoreSize(long, long, long) - Method in class org.apache.hadoop.hbase.regionserver.RegionServerAccounting
 
DecimalStringSplit() - Constructor for class org.apache.hadoop.hbase.util.RegionSplitter.DecimalStringSplit
 
decMemStoreSize(long, long, long, int) - Method in interface org.apache.hadoop.hbase.regionserver.MemStoreSizing
Returns The new dataSize ONLY as a convenience
decMemStoreSize(MemStoreSize) - Method in interface org.apache.hadoop.hbase.regionserver.MemStoreSizing
 
decode(PositionedByteRange) - Method in interface org.apache.hadoop.hbase.types.DataType
Read an instance of T from the buffer src.
decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.FixedLengthWrapper
 
decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedBlob
 
decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedBlobVar
 
decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedFloat32
 
decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedFloat64
 
decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedInt16
 
decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedInt32
 
decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedInt64
 
decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedInt8
 
decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedNumeric
 
decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedString
 
decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.PBCell
 
decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawByte
 
decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawBytes
 
decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawDouble
 
decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawFloat
 
decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawInteger
 
decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawLong
 
decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawShort
 
decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawString
 
decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.Struct
 
decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.TerminatedWrapper
 
decode(PositionedByteRange, int) - Method in class org.apache.hadoop.hbase.types.RawBytes
Read a byte[] from the buffer src.
decode(PositionedByteRange, int) - Method in class org.apache.hadoop.hbase.types.RawBytesFixedLength
Read a byte[] from the buffer src.
decode(PositionedByteRange, int) - Method in class org.apache.hadoop.hbase.types.RawBytesTerminated
Read a byte[] from the buffer src.
decode(PositionedByteRange, int) - Method in class org.apache.hadoop.hbase.types.Struct
Read the field at index.
decode(ChannelHandlerContext, ByteBuf, List<Object>) - Method in class org.apache.hadoop.hbase.io.asyncfs.ProtobufDecoder
 
decode(ChannelHandlerContext, ByteBuf, List<Object>) - Method in class org.apache.hadoop.hbase.security.SaslChallengeDecoder
 
decodeA(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.Union2
Read an instance of the first type parameter from buffer src.
decodeAtPosition(int) - Method in class org.apache.hadoop.hbase.io.encoding.RowIndexSeekerV1
 
decodeB(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.Union2
Read an instance of the second type parameter from buffer src.
decodeBlobCopy(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Decode a Blob value, byte-for-byte copy.
decodeBlobVar(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Decode a blob value that was encoded using BlobVar encoding.
decodeByte(byte[], int) - Method in class org.apache.hadoop.hbase.types.RawByte
Read a byte value from the buffer buff.
decodeByte(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedInt8
Read a byte value from the buffer src.
decodeC(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.Union3
Read an instance of the third type parameter from buffer src.
decodeD(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.Union4
Read an instance of the fourth type parameter from buffer src.
decodeDouble(byte[], int) - Method in class org.apache.hadoop.hbase.types.RawDouble
Read a double value from the buffer buff.
decodeDouble(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedFloat64
Read a double value from the buffer src.
decodeDouble(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedNumeric
Read a double value from the buffer src.
decodeFirst() - Method in class org.apache.hadoop.hbase.io.encoding.RowIndexSeekerV1
 
decodeFloat(byte[], int) - Method in class org.apache.hadoop.hbase.types.RawFloat
Read a float value from the buffer buff.
decodeFloat(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedFloat32
Read a float value from the buffer dst.
decodeFloat32(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Decode a 32-bit floating point value using the fixed-length encoding.
decodeFloat64(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Decode a 64-bit floating point value using the fixed-length encoding.
decodeIdentifier(String) - Static method in class org.apache.hadoop.hbase.security.SaslUtil
 
decodeInt(byte[], int) - Method in class org.apache.hadoop.hbase.types.RawInteger
Read an int value from the buffer buff.
decodeInt(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedInt32
Read an int value from the buffer src.
decodeInt16(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Decode an int16 value.
decodeInt32(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Decode an int32 value.
decodeInt64(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Decode an int64 value.
decodeInt8(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Decode an int8 value.
decodeKeyValues(DataInputStream, HFileBlockDecodingContext) - Method in class org.apache.hadoop.hbase.io.encoding.CopyKeyDataBlockEncoder
 
decodeKeyValues(DataInputStream, HFileBlockDecodingContext) - Method in interface org.apache.hadoop.hbase.io.encoding.DataBlockEncoder
Decode.
decodeKeyValues(DataInputStream, HFileBlockDecodingContext) - Method in class org.apache.hadoop.hbase.io.encoding.RowIndexCodecV1
 
decodeLong(byte[], int) - Method in class org.apache.hadoop.hbase.types.RawLong
Read a long value from the buffer buff.
decodeLong(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedInt64
Read a long value from the buffer src.
decodeLong(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedNumeric
Read a long value from the buffer src.
decodeNext() - Method in class org.apache.hadoop.hbase.io.encoding.RowIndexSeekerV1
 
decodeNumericAsBigDecimal(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Decode a BigDecimal value from the variable-length encoding.
decodeNumericAsDouble(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Decode a primitive double value from the Numeric encoding.
decodeNumericAsLong(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Decode a primitive long value from the Numeric encoding.
decodeShort(byte[], int) - Method in class org.apache.hadoop.hbase.types.RawShort
Read a short value from the buffer buff.
decodeShort(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedInt16
Read a short value from the buffer src.
decodeString(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Decode a String value.
decodeTags() - Method in class org.apache.hadoop.hbase.io.encoding.RowIndexSeekerV1
 
decodingCtx - Variable in class org.apache.hadoop.hbase.io.encoding.AbstractDataBlockEncoder.AbstractEncodedSeeker
 
org.apache.hadoop.hbase.ipc.DecommissionedHostRejectedException - Exception in org.apache.hadoop.hbase.ipc
 
DecommissionedHostRejectedException(String) - Constructor for exception org.apache.hadoop.hbase.ipc.DecommissionedHostRejectedException
 
decommissionRegionServers(List<ServerName>, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
Mark region server(s) as decommissioned to prevent additional regions from getting assigned to them.
decommissionRegionServers(List<ServerName>, boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Mark region server(s) as decommissioned to prevent additional regions from getting assigned to them.
decommissionRegionServers(List<ServerName>, boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
decommissionRegionServers(List<ServerName>, boolean) - Method in class org.apache.hadoop.hbase.master.HMaster
Mark region server(s) as decommissioned (previously called 'draining') to prevent additional regions from getting assigned to them.
decommissionRegionServers(RpcController, MasterProtos.DecommissionRegionServersRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
decommissionRegionServers(RpcController, MasterProtos.DecommissionRegionServersRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
 
decorateMasterConfiguration(Configuration) - Static method in class org.apache.hadoop.hbase.master.HMaster
This method modifies the master's configuration in order to inject replication-related features
decorateTask(Runnable, RunnableScheduledFuture<V>) - Method in class org.apache.hadoop.hbase.JitterScheduledThreadPoolExecutorImpl
 
decorateTask(Callable<V>, RunnableScheduledFuture<V>) - Method in class org.apache.hadoop.hbase.JitterScheduledThreadPoolExecutorImpl
 
decrement() - Method in interface org.apache.hadoop.hbase.metrics.Counter
Decrement this by 1.
decrement() - Method in class org.apache.hadoop.hbase.util.Counter
Deprecated.
 
decrement(long) - Method in interface org.apache.hadoop.hbase.metrics.Counter
Decrement this by n.
decrementCompactionsQueuedCount() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
decrementFlushesQueuedCount() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
decrypt(byte[], int, InputStream, int, Decryptor) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
Decrypt a block of ciphertext read in from a stream with the given cipher and context
decrypt(byte[], int, InputStream, int, Encryption.Context, byte[]) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
Decrypt a block of ciphertext from a stream given a context and IV
decrypt(OutputStream, InputStream, int, Decryptor) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
Decrypt a stream of ciphertext given a decryptor
decrypt(OutputStream, InputStream, int, Encryption.Context, byte[]) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
Decrypt a stream of ciphertext given a context and IV
decryptor - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractProtobufWALReader
 
org.apache.hadoop.hbase.io.crypto.Decryptor - Interface in org.apache.hadoop.hbase.io.crypto
Decryptors apply a cipher to an InputStream to recover plaintext.
decryptWithSubjectKey(OutputStream, InputStream, int, String, Configuration, Cipher, byte[]) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
Decrypts a block of ciphertext with the symmetric key resolved for the given subject
decScannerCount() - Method in class org.apache.hadoop.hbase.regionserver.CompositeImmutableSegment
 
decScannerCount() - Method in class org.apache.hadoop.hbase.regionserver.ImmutableMemStoreLAB
 
decScannerCount() - Method in interface org.apache.hadoop.hbase.regionserver.MemStoreLAB
Called when closing a scanner on the data of this MemStoreLAB
decScannerCount() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreLABImpl
Called when closing a scanner on the data of this MemStoreLAB
decScannerCount() - Method in class org.apache.hadoop.hbase.regionserver.Segment
 
decTaskCounters(Collection<byte[]>, ServerName) - Method in interface org.apache.hadoop.hbase.client.RequestController
Decrement the counter if a task is accomplished.
DEEP_COPY - Enum constant in enum org.apache.hadoop.hbase.CellBuilderType
The cell builder will copy all passed bytes for building cell.
DEEP_OVERHEAD - Static variable in class org.apache.hadoop.hbase.regionserver.AbstractMemStore
 
DEEP_OVERHEAD - Static variable in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
 
DEEP_OVERHEAD - Static variable in class org.apache.hadoop.hbase.regionserver.CompactionPipeline
 
DEEP_OVERHEAD - Static variable in class org.apache.hadoop.hbase.regionserver.DefaultMemStore
 
DEEP_OVERHEAD - Static variable in class org.apache.hadoop.hbase.regionserver.HRegion
 
DEEP_OVERHEAD - Static variable in class org.apache.hadoop.hbase.regionserver.HStore
 
DEEP_OVERHEAD - Static variable in class org.apache.hadoop.hbase.regionserver.ImmutableSegment
 
DEEP_OVERHEAD - Static variable in class org.apache.hadoop.hbase.regionserver.MemStoreCompactor
 
DEEP_OVERHEAD - Static variable in class org.apache.hadoop.hbase.regionserver.MutableSegment
 
DEEP_OVERHEAD - Static variable in class org.apache.hadoop.hbase.regionserver.Segment
 
DEEP_OVERHEAD_CAM - Static variable in class org.apache.hadoop.hbase.regionserver.CellArrayImmutableSegment
 
DEEP_OVERHEAD_CCM - Static variable in class org.apache.hadoop.hbase.regionserver.CellChunkImmutableSegment
 
DEEP_OVERHEAD_CSLM - Static variable in class org.apache.hadoop.hbase.regionserver.CSLMImmutableSegment
 
deepClone() - Method in class org.apache.hadoop.hbase.ByteBufferKeyValue
 
deepClone() - Method in interface org.apache.hadoop.hbase.ExtendedCell
Does a deep copy of the contents to a new memory area and returns it as a new cell.
deepClone() - Method in class org.apache.hadoop.hbase.KeyValue
 
deepClone() - Method in class org.apache.hadoop.hbase.NoTagsByteBufferKeyValue
 
deepClone() - Method in class org.apache.hadoop.hbase.NoTagsKeyValue
 
deepClone() - Method in class org.apache.hadoop.hbase.util.MapReduceExtendedCell
 
deepClone(Cell) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
Deep clones the given cell if the cell supports deep cloning
deepCopy() - Method in interface org.apache.hadoop.hbase.util.ByteRange
Create a new ByteRange with new backing byte[] containing a copy of the content from this range's window.
deepCopy() - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
 
deepCopy() - Method in class org.apache.hadoop.hbase.util.SimpleByteRange
 
deepCopy() - Method in class org.apache.hadoop.hbase.util.SimpleMutableByteRange
 
deepCopy() - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
 
deepCopy() - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
 
deepCopySubRangeTo(int, int, byte[], int) - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
 
deepCopySubRangeTo(int, int, byte[], int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
Wrapper for System.arraycopy.
deepCopyTo(byte[], int) - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
 
deepCopyTo(byte[], int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
Wrapper for System.arraycopy.
deepCopyToNewArray() - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
 
deepCopyToNewArray() - Method in interface org.apache.hadoop.hbase.util.ByteRange
Instantiate a new byte[] with exact length, which is at least 24 bytes + length.
DEFAULT - Enum constant in enum org.apache.hadoop.hbase.client.Scan.ReadType
 
DEFAULT - Enum constant in enum org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileTrackerFactory.Trackers
 
DEFAULT - Static variable in class org.apache.hadoop.hbase.ipc.HeapByteBufAllocator
 
DEFAULT - Static variable in enum org.apache.hadoop.hbase.thrift.ImplType
 
DEFAULT_ABORT_ON_ERROR - Static variable in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
 
DEFAULT_AGGREGATION_WINDOW - Static variable in class org.apache.hadoop.hbase.regionserver.BusyRegionSplitPolicy
 
DEFAULT_ASYNC_DFS_OUTPUT_CREATE_MAX_RETRIES - Static variable in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputHelper
 
DEFAULT_ASYNC_WAL_USE_SHARED_EVENT_LOOP - Static variable in class org.apache.hadoop.hbase.regionserver.wal.AsyncFSWAL
 
DEFAULT_ASYNC_WAL_WAIT_ON_SHUTDOWN_IN_SECONDS - Static variable in class org.apache.hadoop.hbase.regionserver.wal.AsyncFSWAL
 
DEFAULT_ATTRIBUTES_COLUMN_INDEX - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
 
DEFAULT_BACKUP_ATTEMPTS_PAUSE_MS - Static variable in interface org.apache.hadoop.hbase.backup.BackupRestoreConstants
 
DEFAULT_BACKUP_MAX_ATTEMPTS - Static variable in interface org.apache.hadoop.hbase.backup.BackupRestoreConstants
 
DEFAULT_BIND_ADDR - Static variable in class org.apache.hadoop.hbase.thrift.Constants
 
DEFAULT_BLOCK_STORAGE_POLICY - Static variable in class org.apache.hadoop.hbase.regionserver.HStore
 
DEFAULT_BLOCKCACHE - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
Default setting for whether to use a block cache or not.
DEFAULT_BLOCKCACHE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
DEFAULT_BLOCKING_STOREFILE_COUNT - Static variable in class org.apache.hadoop.hbase.regionserver.HStore
 
DEFAULT_BLOCKSIZE - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
Default size of blocks in files stored to the filesytem (hfiles).
DEFAULT_BLOCKSIZE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
DEFAULT_BLOCKSIZE - Static variable in class org.apache.hadoop.hbase.HConstants
Default block size for an HFile.
DEFAULT_BLOOMFILTER - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
Default setting for whether or not to use bloomfilters.
DEFAULT_BLOOMFILTER - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
DEFAULT_BROKEN_STOREFILE_CLEANER_DELAY - Static variable in class org.apache.hadoop.hbase.regionserver.BrokenStoreFileCleaner
 
DEFAULT_BROKEN_STOREFILE_CLEANER_DELAY_JITTER - Static variable in class org.apache.hadoop.hbase.regionserver.BrokenStoreFileCleaner
 
DEFAULT_BROKEN_STOREFILE_CLEANER_ENABLED - Static variable in class org.apache.hadoop.hbase.regionserver.BrokenStoreFileCleaner
 
DEFAULT_BROKEN_STOREFILE_CLEANER_PERIOD - Static variable in class org.apache.hadoop.hbase.regionserver.BrokenStoreFileCleaner
 
DEFAULT_BROKEN_STOREFILE_CLEANER_TTL - Static variable in class org.apache.hadoop.hbase.regionserver.BrokenStoreFileCleaner
 
DEFAULT_BUCKET_CACHE_WRITER_QUEUE - Static variable in class org.apache.hadoop.hbase.io.hfile.BlockCacheFactory
 
DEFAULT_BUCKET_CACHE_WRITER_THREADS - Static variable in class org.apache.hadoop.hbase.io.hfile.BlockCacheFactory
Defaults for Bucket cache
DEFAULT_BUFFER_SIZE - Static variable in class org.apache.hadoop.hbase.io.ByteBuffAllocator
There're some reasons why better to choose 65KB(rather than 64KB) as the default buffer size:
DEFAULT_BUFFER_SIZE - Static variable in class org.apache.hadoop.hbase.util.ByteBufferArray
 
DEFAULT_BYTES_PER_CHECKSUM - Static variable in class org.apache.hadoop.hbase.io.hfile.HFile
The number of bytes per checksum.
DEFAULT_BYTES_PER_CHECKSUM - Static variable in class org.apache.hadoop.hbase.io.hfile.HFileContextBuilder
 
DEFAULT_CACHE_BLOOMS_ON_WRITE - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
Default setting for whether to cache bloom filter blocks on write if block caching is enabled.
DEFAULT_CACHE_BLOOMS_ON_WRITE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
DEFAULT_CACHE_BLOOMS_ON_WRITE - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
 
DEFAULT_CACHE_COMPACTED_BLOCKS_ON_WRITE - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
 
DEFAULT_CACHE_COMPACTED_BLOCKS_ON_WRITE_THRESHOLD - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
 
DEFAULT_CACHE_DATA_COMPRESSED - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
 
DEFAULT_CACHE_DATA_IN_L1 - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
DEFAULT_CACHE_DATA_ON_READ - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
 
DEFAULT_CACHE_DATA_ON_WRITE - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
Default setting for whether to cache data blocks on write if block caching is enabled.
DEFAULT_CACHE_DATA_ON_WRITE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
DEFAULT_CACHE_DATA_ON_WRITE - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
 
DEFAULT_CACHE_FLUSH_INTERVAL - Static variable in class org.apache.hadoop.hbase.regionserver.HRegion
Default interval for the memstore flush
DEFAULT_CACHE_INDEX_ON_WRITE - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
Default setting for whether to cache index blocks on write if block caching is enabled.
DEFAULT_CACHE_INDEX_ON_WRITE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
DEFAULT_CACHE_INDEXES_ON_WRITE - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
 
DEFAULT_CALL_QUEUE_SIZE_HARD_LIMIT - Static variable in class org.apache.hadoop.hbase.ipc.RpcExecutor
 
DEFAULT_CELL_TTL_COLUMN_INDEX - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
 
DEFAULT_CELL_VISIBILITY_COLUMN_INDEX - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
 
DEFAULT_CHORE_SERVICE_INITIAL_POOL_SIZE - Static variable in class org.apache.hadoop.hbase.ChoreService
 
DEFAULT_CLIENT_BOOTSTRAP_NODE_LIMIT - Static variable in class org.apache.hadoop.hbase.regionserver.RSRpcServices
 
DEFAULT_CLIENT_ZOOKEEPER_OBSERVER_MODE - Static variable in class org.apache.hadoop.hbase.HConstants
Assuming client zk not in observer mode and master need to synchronize information
DEFAULT_CLOSE_WAIT_ABORT - Static variable in class org.apache.hadoop.hbase.regionserver.HRegion
 
DEFAULT_CLOSE_WAIT_INTERVAL - Static variable in class org.apache.hadoop.hbase.regionserver.HRegion
 
DEFAULT_CLOSE_WAIT_TIME - Static variable in class org.apache.hadoop.hbase.regionserver.HRegion
 
DEFAULT_CLUSTER_DISTRIBUTED - Static variable in class org.apache.hadoop.hbase.HConstants
Default value for cluster distributed mode
DEFAULT_CLUSTER_ID - Static variable in class org.apache.hadoop.hbase.HConstants
Default cluster ID, cannot be used to identify a cluster so a key with this value means it wasn't meant for replication.
DEFAULT_CODEC_CLASS - Static variable in interface org.apache.hadoop.hbase.ipc.RpcClient
 
DEFAULT_COMPACTCHECKER_INTERVAL_MULTIPLIER - Static variable in class org.apache.hadoop.hbase.regionserver.HStore
 
DEFAULT_COMPACTION_ENABLED - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
Constant that denotes whether the table is compaction enabled by default
DEFAULT_COMPACTION_ENABLED - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
 
DEFAULT_COMPACTION_POLICY_CLASS_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.DefaultStoreEngine
 
DEFAULT_COMPACTOR_CLASS_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.DefaultStoreEngine
 
DEFAULT_COMPRESS_TAGS - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
Default compress tags along with any type of DataBlockEncoding.
DEFAULT_COMPRESS_TAGS - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
DEFAULT_COMPRESSION - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
Default compression type.
DEFAULT_COMPRESSION - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
DEFAULT_COMPRESSION - Static variable in class org.apache.hadoop.hbase.io.hfile.HFile
Default compression name: none.
DEFAULT_COMPRESSION_ALGORITHM - Static variable in class org.apache.hadoop.hbase.io.hfile.HFile
Default compression: none.
DEFAULT_CONCURRENCY_LEVEL - Static variable in class org.apache.hadoop.hbase.util.ObjectPool
The default concurrency level, used when not otherwise specified in a constructor.
DEFAULT_COPROCESSORS_ENABLED - Static variable in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
 
DEFAULT_DATA_BLOCK_ENCODING - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
Default data block encoding algorithm.
DEFAULT_DATA_BLOCK_ENCODING - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
DEFAULT_DELEGATE_PROVIDER - Static variable in class org.apache.hadoop.hbase.wal.RegionGroupingProvider
 
DEFAULT_DFS_REPLICATION - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
DEFAULT_DFS_REPLICATION - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
DEFAULT_DICTIONARY_MAX_SIZE - Static variable in class org.apache.hadoop.hbase.io.compress.DictionaryCache
 
DEFAULT_ENABLE_CLIENT_BACKPRESSURE - Static variable in class org.apache.hadoop.hbase.HConstants
 
DEFAULT_ENCODE_ON_DISK - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
DEFAULT_END_TIMESTAMP - Static variable in class org.apache.hadoop.hbase.rest.RowSpec
 
DEFAULT_EVICT_BLOCKS_ON_CLOSE - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
Default setting for whether to evict cached blocks from the blockcache on close.
DEFAULT_EVICT_BLOCKS_ON_CLOSE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
DEFAULT_EVICT_ON_CLOSE - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
 
DEFAULT_EVICT_REMAIN_RATIO - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
 
DEFAULT_FAIR_REENTRANT_CLOSE_LOCK - Static variable in class org.apache.hadoop.hbase.regionserver.HRegion
 
DEFAULT_FLUSH_PER_CHANGES - Static variable in class org.apache.hadoop.hbase.regionserver.HRegion
 
DEFAULT_GROUP - Static variable in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
 
DEFAULT_HANDSHAKE_DETECTION_TIMEOUT_MILLIS - Static variable in class org.apache.hadoop.hbase.io.crypto.tls.X509Util
 
DEFAULT_HBASE_BALANCER_PERIOD - Static variable in class org.apache.hadoop.hbase.HConstants
Default value for the balancer period
DEFAULT_HBASE_CELLS_SCANNED_PER_HEARTBEAT_CHECK - Static variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
Default value of StoreScanner.HBASE_CELLS_SCANNED_PER_HEARTBEAT_CHECK.
DEFAULT_HBASE_CLIENT_MAX_PERREGION_TASKS - Static variable in class org.apache.hadoop.hbase.HConstants
Default value of HConstants.HBASE_CLIENT_MAX_PERREGION_TASKS.
DEFAULT_HBASE_CLIENT_MAX_PERSERVER_TASKS - Static variable in class org.apache.hadoop.hbase.HConstants
Default value of HConstants.HBASE_CLIENT_MAX_PERSERVER_TASKS.
DEFAULT_HBASE_CLIENT_MAX_TOTAL_TASKS - Static variable in class org.apache.hadoop.hbase.HConstants
Default value of HConstants.HBASE_CLIENT_MAX_TOTAL_TASKS.
DEFAULT_HBASE_CLIENT_OPERATION_TIMEOUT - Static variable in class org.apache.hadoop.hbase.HConstants
Default HBase client operation timeout, which is tantamount to a blocking call
DEFAULT_HBASE_CLIENT_PAUSE - Static variable in class org.apache.hadoop.hbase.HConstants
Default value of HConstants.HBASE_CLIENT_PAUSE.
DEFAULT_HBASE_CLIENT_PERSERVER_REQUESTS_THRESHOLD - Static variable in class org.apache.hadoop.hbase.HConstants
Default value of HConstants.HBASE_CLIENT_PERSERVER_REQUESTS_THRESHOLD.
DEFAULT_HBASE_CLIENT_RETRIES_NUMBER - Static variable in class org.apache.hadoop.hbase.HConstants
Default value of HConstants.HBASE_CLIENT_RETRIES_NUMBER.
DEFAULT_HBASE_CLIENT_SCANNER_ASYNC_PREFETCH - Static variable in class org.apache.hadoop.hbase.client.Scan
Default value of Scan.HBASE_CLIENT_SCANNER_ASYNC_PREFETCH.
DEFAULT_HBASE_CLIENT_SCANNER_CACHING - Static variable in class org.apache.hadoop.hbase.HConstants
Default value for HConstants.HBASE_CLIENT_SCANNER_CACHING
DEFAULT_HBASE_CLIENT_SCANNER_MAX_RESULT_SIZE - Static variable in class org.apache.hadoop.hbase.HConstants
Maximum number of bytes returned when calling a scanner's next method.
DEFAULT_HBASE_CLIENT_SCANNER_TIMEOUT_PERIOD - Static variable in class org.apache.hadoop.hbase.HConstants
Default value of HConstants.HBASE_CLIENT_SCANNER_TIMEOUT_PERIOD.
DEFAULT_HBASE_CLIENT_SERVERSIDE_RETRIES_MULTIPLIER - Static variable in class org.apache.hadoop.hbase.HConstants
 
DEFAULT_HBASE_ENABLE_SEPARATE_CHILD_REGIONS - Static variable in class org.apache.hadoop.hbase.HConstants
Default value for automatically separate child regions to different region servers (set to "false" to keep all child regions to the server where parent region is on)
DEFAULT_HBASE_HTTP_STATIC_USER - Static variable in interface org.apache.hadoop.hbase.http.ServerConfigurationKeys
 
DEFAULT_HBASE_JETTY_LOGS_SERVE_ALIASES - Static variable in interface org.apache.hadoop.hbase.http.ServerConfigurationKeys
 
DEFAULT_HBASE_MASTER_BALANCER_MAX_RIT_PERCENT - Static variable in class org.apache.hadoop.hbase.HConstants
Default value for the max percent of regions in transition
DEFAULT_HBASE_MASTER_CLEANER_INTERVAL - Static variable in class org.apache.hadoop.hbase.master.HMaster
 
DEFAULT_HBASE_MASTER_CLUSTER_SCHEMA_OPERATION_TIMEOUT - Static variable in interface org.apache.hadoop.hbase.master.ClusterSchema
Default operation timeout in milliseconds.
DEFAULT_HBASE_MASTER_WAIT_ON_SERVICE_IN_SECONDS - Static variable in class org.apache.hadoop.hbase.master.HMaster
 
DEFAULT_HBASE_META_BLOCK_SIZE - Static variable in class org.apache.hadoop.hbase.HConstants
Default value of HConstants.HBASE_META_BLOCK_SIZE.
DEFAULT_HBASE_META_SCANNER_CACHING - Static variable in class org.apache.hadoop.hbase.HConstants
Default value of HConstants.HBASE_META_SCANNER_CACHING.
DEFAULT_HBASE_META_VERSIONS - Static variable in class org.apache.hadoop.hbase.HConstants
Default value of HConstants.HBASE_META_VERSIONS.
DEFAULT_HBASE_OLDWAL_DIR_SIZE_UPDATER_PERIOD - Static variable in class org.apache.hadoop.hbase.HConstants
Default value for the oldWALs directory size updater period
DEFAULT_HBASE_REGIONSERVER_MINIBATCH_SIZE - Static variable in class org.apache.hadoop.hbase.regionserver.HRegion
 
DEFAULT_HBASE_RPC_SHORTOPERATION_RETRY_PAUSE_TIME - Static variable in class org.apache.hadoop.hbase.HConstants
Default value of HConstants.HBASE_RPC_SHORTOPERATION_RETRY_PAUSE_TIME
DEFAULT_HBASE_RPC_SHORTOPERATION_TIMEOUT - Static variable in class org.apache.hadoop.hbase.HConstants
Default value of HConstants.HBASE_RPC_SHORTOPERATION_TIMEOUT_KEY
DEFAULT_HBASE_RPC_TIMEOUT - Static variable in class org.apache.hadoop.hbase.HConstants
Default value of HConstants.HBASE_RPC_TIMEOUT_KEY
DEFAULT_HBASE_SERVER_NETTY_TLS_WRAP_SIZE - Static variable in class org.apache.hadoop.hbase.io.crypto.tls.X509Util
 
DEFAULT_HBASE_SERVER_PAUSE - Static variable in class org.apache.hadoop.hbase.HConstants
Default value of HConstants.HBASE_SERVER_PAUSE.
DEFAULT_HBASE_SERVER_SCANNER_MAX_RESULT_SIZE - Static variable in class org.apache.hadoop.hbase.HConstants
Maximum number of bytes returned when calling a scanner's next method.
DEFAULT_HBASE_SPLIT_COORDINATED_BY_ZK - Static variable in class org.apache.hadoop.hbase.HConstants
Deprecated.
since 2.4.0 and in 3.0.0, to be removed in 4.0.0.
DEFAULT_HBASE_SPLIT_WAL_MAX_SPLITTER - Static variable in class org.apache.hadoop.hbase.HConstants
 
DEFAULT_HEALTH_FAILURE_THRESHOLD - Static variable in class org.apache.hadoop.hbase.HConstants
 
DEFAULT_HEALTH_SCRIPT_TIMEOUT - Static variable in class org.apache.hadoop.hbase.HConstants
 
DEFAULT_HEAP_OCCUPANCY_HIGH_WATERMARK - Static variable in class org.apache.hadoop.hbase.HConstants
 
DEFAULT_HEAP_OCCUPANCY_LOW_WATERMARK - Static variable in class org.apache.hadoop.hbase.HConstants
 
DEFAULT_HOST - Static variable in class org.apache.hadoop.hbase.HConstants
default host address
DEFAULT_HREGION_COLUMNFAMILY_FLUSH_SIZE_LOWER_BOUND_MIN - Static variable in class org.apache.hadoop.hbase.regionserver.FlushLargeStoresPolicy
 
DEFAULT_HREGION_EDITS_REPLAY_SKIP_ERRORS - Static variable in class org.apache.hadoop.hbase.HConstants
 
DEFAULT_HREGION_MEMSTORE_BLOCK_MULTIPLIER - Static variable in class org.apache.hadoop.hbase.HConstants
Default value for hbase.hregion.memstore.block.multiplier
DEFAULT_HSTORE_OPEN_AND_CLOSE_THREADS_MAX - Static variable in class org.apache.hadoop.hbase.HConstants
The default number for the max number of threads used for opening and closing stores or store files in parallel
DEFAULT_HTTP_MAX_HEADER_SIZE - Static variable in class org.apache.hadoop.hbase.thrift.Constants
 
DEFAULT_IN_MEMORY - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
Default setting for whether to try and serve this column family from memory or not.
DEFAULT_IN_MEMORY - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
DEFAULT_IN_MEMORY - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
 
DEFAULT_INDEX_BLOCK_ENCODING - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
Default index block encoding algorithm.
DEFAULT_INITIAL_CAPACITY - Static variable in class org.apache.hadoop.hbase.util.ObjectPool
The default initial capacity, used when not otherwise specified in a constructor.
DEFAULT_KEEP_DELETED - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
Default setting for preventing deleted from being collected immediately.
DEFAULT_KEEP_DELETED - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
DEFAULT_KEYVALUE_SEPARATOR - Static variable in class org.apache.hadoop.hbase.util.Strings
 
DEFAULT_LISTEN_PORT - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
DEFAULT_LISTEN_PORT - Static variable in class org.apache.hadoop.hbase.thrift.Constants
 
DEFAULT_LOCAL_DIR - Static variable in class org.apache.hadoop.hbase.util.ClassLoaderBase
 
DEFAULT_LOSSY_COUNTING_ERROR_RATE - Static variable in class org.apache.hadoop.hbase.HConstants
 
DEFAULT_MAJOR_COMPACTION_JITTER - Static variable in class org.apache.hadoop.hbase.HConstants
 
DEFAULT_MAJOR_COMPACTION_PERIOD - Static variable in class org.apache.hadoop.hbase.HConstants
 
DEFAULT_MASTER_CHECK_COMPRESSION - Static variable in class org.apache.hadoop.hbase.util.TableDescriptorChecker
 
DEFAULT_MASTER_CHECK_ENCRYPTION - Static variable in class org.apache.hadoop.hbase.util.TableDescriptorChecker
 
DEFAULT_MASTER_HANLDER_COUNT - Static variable in class org.apache.hadoop.hbase.HConstants
Deprecated.
DEFAULT_MASTER_INFOPORT - Static variable in class org.apache.hadoop.hbase.HConstants
default port for master web api
DEFAULT_MASTER_PORT - Static variable in class org.apache.hadoop.hbase.HConstants
default port that the master listens on
DEFAULT_MASTER_TYPE_BACKUP - Static variable in class org.apache.hadoop.hbase.HConstants
by default every master is a possible primary master unless the conf explicitly overrides it
DEFAULT_MATH_CONTEXT - Static variable in class org.apache.hadoop.hbase.util.OrderedBytes
The context used to normalize BigDecimal values.
DEFAULT_MAX_AGE - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
DEFAULT_MAX_ATTEMPTS - Static variable in class org.apache.hadoop.hbase.namequeues.WALEventTrackerTableAccessor
 
DEFAULT_MAX_BACKOFF - Static variable in class org.apache.hadoop.hbase.client.backoff.ExponentialClientBackoffPolicy
 
DEFAULT_MAX_BLOCKED_REQUESTS - Static variable in class org.apache.hadoop.hbase.regionserver.BusyRegionSplitPolicy
 
DEFAULT_MAX_CALLQUEUE_LENGTH_PER_HANDLER - Static variable in class org.apache.hadoop.hbase.ipc.RpcServer
How many calls/handler are allowed in the queue.
DEFAULT_MAX_CALLQUEUE_SIZE - Static variable in class org.apache.hadoop.hbase.ipc.RpcServer
 
DEFAULT_MAX_CELL_SIZE - Static variable in class org.apache.hadoop.hbase.regionserver.HRegion
 
DEFAULT_MAX_FILE_SIZE - Static variable in class org.apache.hadoop.hbase.HConstants
Default maximum file size
DEFAULT_MAX_QUEUED_REQUESTS - Static variable in class org.apache.hadoop.hbase.thrift.TBoundedThreadPoolServer
 
DEFAULT_MAX_REQUEST_SIZE - Static variable in class org.apache.hadoop.hbase.ipc.RpcServer
Default value for above params
DEFAULT_MAX_RESUBMIT - Static variable in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
 
DEFAULT_MAX_SLEEP_TIME - Static variable in class org.apache.hadoop.hbase.namequeues.WALEventTrackerTableAccessor
 
DEFAULT_MAX_VERSIONS - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
Default number of versions of a record to keep.
DEFAULT_MAX_WAIT_TIME - Static variable in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
By default, wait 300 seconds for a snapshot to complete
DEFAULT_MAX_WORKER_THREADS - Static variable in class org.apache.hadoop.hbase.thrift.TBoundedThreadPoolServer
 
DEFAULT_MEMSTORE_FLUSH_SIZE - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
Constant that denotes the maximum default size of the memstore in bytes after which the contents are flushed to the store files.
DEFAULT_MEMSTORE_FLUSH_SIZE - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
 
DEFAULT_MEMSTORE_SIZE - Static variable in class org.apache.hadoop.hbase.io.util.MemorySizeUtil
 
DEFAULT_MEMSTORE_SIZE_LOWER_LIMIT - Static variable in class org.apache.hadoop.hbase.io.util.MemorySizeUtil
 
DEFAULT_MERGE_ENABLED - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
Constant that denotes whether the table is merge enabled by default
DEFAULT_META_CALL_QUEUE_READ_SHARE - Static variable in class org.apache.hadoop.hbase.ipc.MetaRWQueueRpcExecutor
 
DEFAULT_META_REPLICA_NUM - Static variable in class org.apache.hadoop.hbase.HConstants
Deprecated.
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.
DEFAULT_METRIC_USER_ENABLED_CONF - Static variable in class org.apache.hadoop.hbase.regionserver.MetricsUserAggregateFactory
 
DEFAULT_MIN_AGE_MS - Static variable in class org.apache.hadoop.hbase.regionserver.BusyRegionSplitPolicy
 
DEFAULT_MIN_AGE_TO_ARCHIVE - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
 
DEFAULT_MIN_CLIENT_REQUEST_TIMEOUT - Static variable in class org.apache.hadoop.hbase.ipc.RpcServer
 
DEFAULT_MIN_VERSIONS - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
Default is not to keep a minimum of versions.
DEFAULT_MIN_VERSIONS - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
DEFAULT_MIN_WORKER_THREADS - Static variable in class org.apache.hadoop.hbase.thrift.TBoundedThreadPoolServer
This default core pool size should be enough for many test scenarios.
DEFAULT_MOB_CACHE_EVICT_PERIOD - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
 
DEFAULT_MOB_CLEANER_BATCH_SIZE_UPPER_BOUND - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
 
DEFAULT_MOB_CLEANER_PERIOD - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
 
DEFAULT_MOB_COMPACT_PARTITION_POLICY - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
DEFAULT_MOB_COMPACT_PARTITION_POLICY - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
DEFAULT_MOB_COMPACTION_BATCH_SIZE - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
 
DEFAULT_MOB_COMPACTION_CHORE_PERIOD - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
 
DEFAULT_MOB_COMPACTION_MAX_FILE_SIZE - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
Default maximum selection size = 1GB
DEFAULT_MOB_COMPACTION_MERGEABLE_THRESHOLD - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
 
DEFAULT_MOB_COMPACTION_THREADS_MAX - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
 
DEFAULT_MOB_COMPACTION_TYPE - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
 
DEFAULT_MOB_DELFILE_MAX_COUNT - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
 
DEFAULT_MOB_DISCARD_MISS - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
 
DEFAULT_MOB_FILE_CACHE_SIZE - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
 
DEFAULT_MOB_MAJOR_COMPACTION_REGION_BATCH_SIZE - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
Default is 0 - means no limit - all regions of a MOB table will be compacted at once
DEFAULT_MOB_THRESHOLD - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
DEFAULT_MOB_THRESHOLD - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
DEFAULT_MOVE_RETRIES_MAX - Static variable in class org.apache.hadoop.hbase.util.RegionMover
 
DEFAULT_MOVE_WAIT_MAX - Static variable in class org.apache.hadoop.hbase.util.RegionMover
 
DEFAULT_NAMESPACE - Static variable in class org.apache.hadoop.hbase.NamespaceDescriptor
 
DEFAULT_NAMESPACE_NAME - Static variable in class org.apache.hadoop.hbase.NamespaceDescriptor
Default namespace name.
DEFAULT_NAMESPACE_NAME_STR - Static variable in class org.apache.hadoop.hbase.NamespaceDescriptor
 
DEFAULT_NETTY_NATIVETRANSPORT - Static variable in class org.apache.hadoop.hbase.util.NettyEventLoopGroupConfig
 
DEFAULT_NETTY_WORKER_COUNT - Static variable in class org.apache.hadoop.hbase.util.NettyEventLoopGroupConfig
 
DEFAULT_NEW_VERSION_BEHAVIOR - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
DEFAULT_NEW_VERSION_BEHAVIOR - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
DEFAULT_NORMALIZATION_ENABLED - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
Deprecated.
DEFAULT_NORMALIZATION_ENABLED - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
 
DEFAULT_ONLINE_LOG_PROVIDER_ENABLED - Static variable in class org.apache.hadoop.hbase.HConstants
 
DEFAULT_OVERALL_HREGION_FILES - Static variable in class org.apache.hadoop.hbase.HConstants
Default overall region files
DEFAULT_PREFETCH_BLOCKS_ON_OPEN - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
DEFAULT_PREFETCH_BLOCKS_ON_OPEN - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
DEFAULT_PREFETCH_ON_OPEN - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
 
DEFAULT_PROTOCOL - Static variable in class org.apache.hadoop.hbase.io.crypto.tls.X509Util
 
DEFAULT_READ_CAPACITY_UNIT - Static variable in class org.apache.hadoop.hbase.quotas.QuotaUtil
 
DEFAULT_READONLY - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
Constant that denotes whether the table is READONLY by default and is false
DEFAULT_READONLY - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
 
DEFAULT_REASSIGN_WAIT_INTERVAL - Static variable in interface org.apache.hadoop.hbase.rsgroup.RSGroupInfoManager
 
DEFAULT_REGION_GROUPING_STRATEGY - Static variable in class org.apache.hadoop.hbase.wal.RegionGroupingProvider
 
DEFAULT_REGION_MEMSTORE_REPLICATION - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
 
DEFAULT_REGION_MEMSTORE_REPLICATION - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
 
DEFAULT_REGION_REPLICA_WAIT_FOR_PRIMARY_FLUSH - Static variable in class org.apache.hadoop.hbase.client.RegionReplicaUtil
 
DEFAULT_REGION_REPLICATION - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
 
DEFAULT_REGION_REPLICATION - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
 
DEFAULT_REGION_SERVER_BULKLOAD_HANDLER_COUNT - Static variable in class org.apache.hadoop.hbase.HConstants
 
DEFAULT_REGION_SERVER_HANDLER_ABORT_ON_ERROR_PERCENT - Static variable in class org.apache.hadoop.hbase.HConstants
 
DEFAULT_REGION_SERVER_HANDLER_COUNT - Static variable in class org.apache.hadoop.hbase.HConstants
 
DEFAULT_REGION_SERVER_HIGH_PRIORITY_HANDLER_COUNT - Static variable in class org.apache.hadoop.hbase.HConstants
 
DEFAULT_REGION_SERVER_REGION_SPLIT_LIMIT - Static variable in class org.apache.hadoop.hbase.regionserver.CompactSplit
 
DEFAULT_REGION_SERVER_REPLICATION_HANDLER_COUNT - Static variable in class org.apache.hadoop.hbase.HConstants
 
DEFAULT_REGION_STORAGE_POLICY - Static variable in class org.apache.hadoop.hbase.regionserver.HRegion
 
DEFAULT_REGIONS_RECOVERY_INTERVAL - Static variable in class org.apache.hadoop.hbase.HConstants
 
DEFAULT_REGIONSERVER_INFOPORT - Static variable in class org.apache.hadoop.hbase.HConstants
default port for region server web api
DEFAULT_REGIONSERVER_METRICS_PERIOD - Static variable in class org.apache.hadoop.hbase.HConstants
 
DEFAULT_REGIONSERVER_PORT - Static variable in class org.apache.hadoop.hbase.HConstants
Default port region server listens on.
DEFAULT_REPLICA_ID - Static variable in interface org.apache.hadoop.hbase.client.RegionInfo
 
DEFAULT_REPLICATION_PEER_STORAGE_IMPL - Static variable in class org.apache.hadoop.hbase.replication.ReplicationStorageFactory
 
DEFAULT_REPLICATION_SCOPE - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
Default scope.
DEFAULT_REPLICATION_SCOPE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
DEFAULT_REQUEST_MASTER_INTERVAL_SECS - Static variable in class org.apache.hadoop.hbase.regionserver.BootstrapNodeManager
 
DEFAULT_REQUEST_MASTER_MIN_INTERVAL_SECS - Static variable in class org.apache.hadoop.hbase.regionserver.BootstrapNodeManager
 
DEFAULT_REQUEST_REGIONSERVER_INTERVAL_SECS - Static variable in class org.apache.hadoop.hbase.regionserver.BootstrapNodeManager
 
DEFAULT_REST_CLIENT_CONN_TIMEOUT - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
DEFAULT_REST_CLIENT_SOCKET_TIMEOUT - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
DEFAULT_REST_SCANNERCACHE_EXPIRE_TIME_MS - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
DEFAULT_REST_SCANNERCACHE_SIZE - Static variable in interface org.apache.hadoop.hbase.rest.Constants
 
DEFAULT_RETRY_ATTEMPTS - Static variable in class org.apache.hadoop.hbase.chaos.ChaosConstants
 
DEFAULT_RETRY_SLEEP_INTERVAL - Static variable in class org.apache.hadoop.hbase.chaos.ChaosConstants
 
DEFAULT_ROLL_ON_SYNC_TIME_MS - Static variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
 
DEFAULT_SEPARATE_OLDLOGDIR - Static variable in class org.apache.hadoop.hbase.wal.AbstractFSWALProvider
 
DEFAULT_SEPARATOR - Static variable in class org.apache.hadoop.hbase.util.Strings
 
DEFAULT_SERVERSTART_WAIT_MAX - Static variable in class org.apache.hadoop.hbase.util.RegionMover
 
DEFAULT_SHELL_TIMESTAMP_FORMAT_EPOCH - Static variable in class org.apache.hadoop.hbase.HConstants
 
DEFAULT_SHELL_USER - Static variable in class org.apache.hadoop.hbase.chaos.ChaosConstants
 
DEFAULT_SIZE - Static variable in class org.apache.hadoop.hbase.util.WindowMovingAverage
 
DEFAULT_SKIP_LOAD_DUPLICATE_TABLE_COPROCESSOR - Static variable in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
 
DEFAULT_SLEEP_BEFORE_RERUN - Static variable in class org.apache.hadoop.hbase.util.HBaseFsck
Deprecated.
 
DEFAULT_SLEEP_INTERVAL - Static variable in class org.apache.hadoop.hbase.namequeues.WALEventTrackerTableAccessor
 
DEFAULT_SLOW_LOG_RING_BUFFER_SIZE - Static variable in class org.apache.hadoop.hbase.HConstants
 
DEFAULT_SLOW_LOG_SYS_TABLE_CHORE_DURATION - Static variable in class org.apache.hadoop.hbase.HConstants
 
DEFAULT_SLOW_LOG_SYS_TABLE_ENABLED_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
 
DEFAULT_SLOW_METRIC_TIME - Static variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
 
DEFAULT_SLOW_RESPONSE_NANO_SEC - Static variable in class org.apache.hadoop.hbase.thrift.ThriftMetrics
 
DEFAULT_SLOW_SYNC_ROLL_INTERVAL_MS - Static variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
 
DEFAULT_SLOW_SYNC_ROLL_THRESHOLD - Static variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
 
DEFAULT_SLOW_SYNC_TIME_MS - Static variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
 
DEFAULT_SNAPSHOT_RESTORE_FAILSAFE_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
 
DEFAULT_SNAPSHOT_RESTORE_TAKE_FAILSAFE_SNAPSHOT - Static variable in class org.apache.hadoop.hbase.HConstants
 
DEFAULT_SNAPSHOT_TTL - Static variable in class org.apache.hadoop.hbase.HConstants
 
DEFAULT_SNAPSHOT_TTL_CONFIG_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
 
DEFAULT_SOCKET_TIMEOUT_CONNECT - Static variable in interface org.apache.hadoop.hbase.ipc.RpcClient
 
DEFAULT_SOCKET_TIMEOUT_READ - Static variable in interface org.apache.hadoop.hbase.ipc.RpcClient
 
DEFAULT_SOCKET_TIMEOUT_WRITE - Static variable in interface org.apache.hadoop.hbase.ipc.RpcClient
 
DEFAULT_SPLIT_ENABLED - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
Constant that denotes whether the table is split enabled by default
DEFAULT_START_TIMESTAMP - Static variable in class org.apache.hadoop.hbase.rest.RowSpec
 
DEFAULT_STATUS_MULTICAST_ADDRESS - Static variable in class org.apache.hadoop.hbase.HConstants
 
DEFAULT_STATUS_MULTICAST_BIND_ADDRESS - Static variable in class org.apache.hadoop.hbase.HConstants
 
DEFAULT_STATUS_MULTICAST_PORT - Static variable in class org.apache.hadoop.hbase.HConstants
 
DEFAULT_STATUS_MULTICAST_PUBLISHER_BIND_ADDRESS - Static variable in class org.apache.hadoop.hbase.HConstants
 
DEFAULT_STATUS_PUBLISH_PERIOD - Static variable in class org.apache.hadoop.hbase.master.ClusterStatusPublisher
 
DEFAULT_STATUS_PUBLISHER_CLASS - Static variable in class org.apache.hadoop.hbase.master.ClusterStatusPublisher
 
DEFAULT_STORE_FILE_READER_NO_READAHEAD - Static variable in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
 
DEFAULT_STORE_FILE_REF_COUNT_THRESHOLD - Static variable in class org.apache.hadoop.hbase.HConstants
 
DEFAULT_STORE_FLUSHER_CLASS_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.DefaultStoreEngine
 
DEFAULT_TABLE_SANITY_CHECKS - Static variable in class org.apache.hadoop.hbase.util.TableDescriptorChecker
 
DEFAULT_TEMPORARY_HDFS_DIRECTORY - Static variable in class org.apache.hadoop.hbase.HConstants
 
DEFAULT_THREAD_WAKE_FREQUENCY - Static variable in class org.apache.hadoop.hbase.HConstants
Default value for thread wake frequency
DEFAULT_TIME_LAG - Static variable in class org.apache.hadoop.hbase.util.HBaseFsck
Deprecated.
 
DEFAULT_TIME_UNIT - Static variable in class org.apache.hadoop.hbase.quotas.RateLimiter
 
DEFAULT_TIMEOUT - Static variable in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
 
DEFAULT_TIMESTAMP_COLUMN_INDEX - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
 
DEFAULT_TRACE_LOG_MAX_LENGTH - Static variable in class org.apache.hadoop.hbase.ipc.RpcServer
 
DEFAULT_TTL - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
Default time to live of cell contents.
DEFAULT_TTL - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
DEFAULT_UNASSIGNED_TIMEOUT - Static variable in class org.apache.hadoop.hbase.master.SplitLogManager
Deprecated.
 
DEFAULT_UNSAFE_HBASE_CLIENT_KERBEROS_HOSTNAME_DISABLE_REVERSEDNS - Static variable in class org.apache.hadoop.hbase.security.SecurityConstants
 
DEFAULT_USE_META_CELL_COMPARATOR - Static variable in class org.apache.hadoop.hbase.regionserver.HRegion
 
DEFAULT_USE_META_REPLICAS - Static variable in class org.apache.hadoop.hbase.HConstants
 
DEFAULT_USER_COPROCESSORS_ENABLED - Static variable in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
 
DEFAULT_VERSION_FILE_WRITE_ATTEMPTS - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for how often we should try to write a version file, before failing
DEFAULT_VERSIONS - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
DEFAULT_WAL_BATCH_SIZE - Static variable in class org.apache.hadoop.hbase.regionserver.wal.AsyncFSWAL
 
DEFAULT_WAL_EXCLUDE_DATANODE_TTL - Static variable in class org.apache.hadoop.hbase.io.asyncfs.monitor.ExcludeDatanodeManager
 
DEFAULT_WAL_HSYNC - Static variable in class org.apache.hadoop.hbase.regionserver.HRegion
 
DEFAULT_WAL_MAX_EXCLUDE_SLOW_DATANODE_COUNT - Static variable in class org.apache.hadoop.hbase.io.asyncfs.monitor.ExcludeDatanodeManager
 
DEFAULT_WAL_ROLL_WAIT_TIMEOUT - Static variable in class org.apache.hadoop.hbase.wal.AbstractWALRoller
 
DEFAULT_WAL_SHUTDOWN_WAIT_TIMEOUT_MS - Static variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
 
DEFAULT_WAL_SPLIT_TO_HFILE - Static variable in class org.apache.hadoop.hbase.wal.WALSplitter
 
DEFAULT_WAL_STORAGE_POLICY - Static variable in class org.apache.hadoop.hbase.HConstants
By default we defer the WAL storage policy to HDFS
DEFAULT_WAL_SYNC_TIMEOUT_MS - Static variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
 
DEFAULT_WARN_RESPONSE_SIZE - Static variable in class org.apache.hadoop.hbase.ipc.RpcServer
 
DEFAULT_WARN_RESPONSE_TIME - Static variable in class org.apache.hadoop.hbase.ipc.RpcServer
 
DEFAULT_WRITE_CAPACITY_UNIT - Static variable in class org.apache.hadoop.hbase.quotas.QuotaUtil
 
DEFAULT_ZK_RETRIES - Static variable in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
 
DEFAULT_ZK_SESSION_TIMEOUT - Static variable in class org.apache.hadoop.hbase.HConstants
Default value for ZooKeeper session timeout
DEFAULT_ZOOKEEPER_CLIENT_PORT - Static variable in class org.apache.hadoop.hbase.HConstants
Default client port that the zookeeper listens on
DEFAULT_ZOOKEEPER_MAX_CLIENT_CNXNS - Static variable in class org.apache.hadoop.hbase.HConstants
Default limit on concurrent client-side zookeeper connections
DEFAULT_ZOOKEEPER_ZNODE_PARENT - Static variable in class org.apache.hadoop.hbase.HConstants
 
DEFAULT_ZOOKEPER_CLIENT_PORT - Static variable in class org.apache.hadoop.hbase.HConstants
Deprecated.
use HConstants.DEFAULT_ZOOKEEPER_CLIENT_PORT instead
DEFAULT_ZOOKEPER_MAX_CLIENT_CNXNS - Static variable in class org.apache.hadoop.hbase.HConstants
Deprecated.
use HConstants.DEFAULT_ZOOKEEPER_MAX_CLIENT_CNXNS instead
DEFAULT_ZOOKEPER_RECOVERABLE_WAITIME - Static variable in class org.apache.hadoop.hbase.HConstants
Deprecated.
org.apache.hadoop.hbase.io.crypto.DefaultCipherProvider - Class in org.apache.hadoop.hbase.io.crypto
The default cipher provider.
defaultContexts - Variable in class org.apache.hadoop.hbase.http.HttpServer
 
org.apache.hadoop.hbase.util.DefaultEnvironmentEdge - Class in org.apache.hadoop.hbase.util
Default implementation of an environment edge.
DefaultEnvironmentEdge() - Constructor for class org.apache.hadoop.hbase.util.DefaultEnvironmentEdge
 
defaultInstance() - Static method in class org.apache.hadoop.hbase.client.BalanceRequest
Get a BalanceRequest for a default run of the balancer.
org.apache.hadoop.hbase.regionserver.DefaultMemStore - Class in org.apache.hadoop.hbase.regionserver
The MemStore holds in-memory modifications to the Store.
DefaultMemStore() - Constructor for class org.apache.hadoop.hbase.regionserver.DefaultMemStore
Default constructor.
DefaultMemStore(Configuration, CellComparator) - Constructor for class org.apache.hadoop.hbase.regionserver.DefaultMemStore
Constructor.
DefaultMemStore(Configuration, CellComparator, RegionServicesForStores) - Constructor for class org.apache.hadoop.hbase.regionserver.DefaultMemStore
Constructor.
org.apache.hadoop.hbase.mob.DefaultMobStoreCompactor - Class in org.apache.hadoop.hbase.mob
Compact passed set of files in the mob-enabled column family.
DefaultMobStoreCompactor(Configuration, HStore) - Constructor for class org.apache.hadoop.hbase.mob.DefaultMobStoreCompactor
 
org.apache.hadoop.hbase.mob.DefaultMobStoreFlusher - Class in org.apache.hadoop.hbase.mob
An implementation of the StoreFlusher.
DefaultMobStoreFlusher(Configuration, HStore) - Constructor for class org.apache.hadoop.hbase.mob.DefaultMobStoreFlusher
 
org.apache.hadoop.hbase.quotas.DefaultOperationQuota - Class in org.apache.hadoop.hbase.quotas
 
DefaultOperationQuota(Configuration, int, QuotaLimiter...) - Constructor for class org.apache.hadoop.hbase.quotas.DefaultOperationQuota
 
DefaultOperationQuota(Configuration, List<QuotaLimiter>) - Constructor for class org.apache.hadoop.hbase.quotas.DefaultOperationQuota
NOTE: The order matters.
org.apache.hadoop.hbase.regionserver.DefaultStoreEngine - Class in org.apache.hadoop.hbase.regionserver
Default StoreEngine creates the default compactor, policy, and store file manager, or their derivatives.
DefaultStoreEngine() - Constructor for class org.apache.hadoop.hbase.regionserver.DefaultStoreEngine
 
org.apache.hadoop.hbase.regionserver.DefaultStoreFlusher - Class in org.apache.hadoop.hbase.regionserver
Default implementation of StoreFlusher.
DefaultStoreFlusher(Configuration, HStore) - Constructor for class org.apache.hadoop.hbase.regionserver.DefaultStoreFlusher
 
org.apache.hadoop.hbase.quotas.policies.DefaultViolationPolicyEnforcement - Class in org.apache.hadoop.hbase.quotas.policies
The default implementation for SpaceViolationPolicyEnforcement.
DefaultViolationPolicyEnforcement() - Constructor for class org.apache.hadoop.hbase.quotas.policies.DefaultViolationPolicyEnforcement
 
org.apache.hadoop.hbase.mapreduce.DefaultVisibilityExpressionResolver - Class in org.apache.hadoop.hbase.mapreduce
This implementation creates tags by expanding expression using label ordinal.
DefaultVisibilityExpressionResolver() - Constructor for class org.apache.hadoop.hbase.mapreduce.DefaultVisibilityExpressionResolver
 
DEFER_TO_HDFS_STORAGE_POLICY - Static variable in class org.apache.hadoop.hbase.HConstants
"NONE" is not a valid storage policy and means we defer the policy to HDFS.
defineFilter(ServletContextHandler, String, String, Map<String, String>, String[]) - Static method in class org.apache.hadoop.hbase.http.HttpServer
Define a filter for a context and set up default url mappings.
defMasterRMIRegistryPort - Static variable in class org.apache.hadoop.hbase.JMXListener
 
defRegionserverRMIRegistryPort - Static variable in class org.apache.hadoop.hbase.JMXListener
 
DEGENERATE_REGION - Enum constant in enum org.apache.hadoop.hbase.util.HbckErrorReporter.ERROR_CODE
Deprecated.
 
org.apache.hadoop.hbase.client.DelayingRunner - Class in org.apache.hadoop.hbase.client
A wrapper for a runnable for a group of actions for a single regionserver.
DelayingRunner(long, Map.Entry<byte[], List<Action>>) - Constructor for class org.apache.hadoop.hbase.client.DelayingRunner
 
delColMap - Variable in class org.apache.hadoop.hbase.regionserver.querymatcher.NewVersionBehaviorTracker
 
delegate - Variable in class org.apache.hadoop.hbase.ipc.DelegatingRpcScheduler
 
DELEGATE_PROVIDER - Static variable in class org.apache.hadoop.hbase.wal.RegionGroupingProvider
delegate provider for WAL creation/roll/close, but not support multiwal
delegatee - Variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
delegatee - Variable in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
 
org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController - Class in org.apache.hadoop.hbase.ipc
Simple delegating controller for use with the RpcControllerFactory to help override standard behavior of a HBaseRpcController.
DelegatingHBaseRpcController(HBaseRpcController) - Constructor for class org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
 
org.apache.hadoop.hbase.io.DelegatingInputStream - Class in org.apache.hadoop.hbase.io
An input stream that delegates all operations to another input stream.
DelegatingInputStream(InputStream) - Constructor for class org.apache.hadoop.hbase.io.DelegatingInputStream
 
org.apache.hadoop.hbase.ipc.DelegatingRpcScheduler - Class in org.apache.hadoop.hbase.ipc
Users of the hbase.region.server.rpc.scheduler.factory.class customization config can return an implementation which extends this class in order to minimize impact of breaking interface changes.
DelegatingRpcScheduler(RpcScheduler) - Constructor for class org.apache.hadoop.hbase.ipc.DelegatingRpcScheduler
 
delete() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.InputModeScreenPresenter
 
delete() - Method in class org.apache.hadoop.hbase.util.RotateFile
Deletes the two files used for rotating data.
delete(String) - Method in class org.apache.hadoop.hbase.rest.client.Client
Send a DELETE request
delete(String, int) - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
delete is an idempotent operation.
delete(String, Header) - Method in class org.apache.hadoop.hbase.rest.client.Client
Send a DELETE request
delete(List<Delete>) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
Deletes the specified cells/rows in bulk.
delete(List<Delete>) - Method in class org.apache.hadoop.hbase.client.HTable
 
delete(List<Delete>) - Method in interface org.apache.hadoop.hbase.client.Table
Batch Deletes the specified cells/rows from the table.
delete(FileSystem, Path, boolean) - Static method in class org.apache.hadoop.hbase.util.CommonFSUtils
Calls fs.delete() and returns the value returned by the fs.delete()
delete(Delete) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
Deletes the specified cells/row.
delete(Delete) - Method in class org.apache.hadoop.hbase.client.HTable
 
delete(Delete) - Method in interface org.apache.hadoop.hbase.client.Table
Deletes the specified cells/row.
delete(Delete) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
delete(Delete) - Method in interface org.apache.hadoop.hbase.regionserver.Region
Deletes the specified cells/row.
delete(Cluster, String) - Method in class org.apache.hadoop.hbase.rest.client.Client
Send a DELETE request
delete(Cluster, String, Header) - Method in class org.apache.hadoop.hbase.rest.client.Client
Send a DELETE request
delete(UriInfo) - Method in class org.apache.hadoop.hbase.rest.RowResource
 
delete(UriInfo) - Method in class org.apache.hadoop.hbase.rest.ScannerInstanceResource
 
delete(UriInfo) - Method in class org.apache.hadoop.hbase.rest.SchemaResource
 
org.apache.hadoop.hbase.client.Delete - Class in org.apache.hadoop.hbase.client
Used to perform Delete operations on a single row.
Delete - Enum constant in enum org.apache.hadoop.hbase.Cell.Type
 
Delete - Enum constant in enum org.apache.hadoop.hbase.hbtop.terminal.KeyPress.Type
 
Delete - Enum constant in enum org.apache.hadoop.hbase.KeyValue.Type
 
Delete(byte[]) - Constructor for class org.apache.hadoop.hbase.client.Delete
Create a Delete operation for the specified row.
Delete(byte[], int, int) - Constructor for class org.apache.hadoop.hbase.client.Delete
Create a Delete operation for the specified row and timestamp.
Delete(byte[], int, int, long) - Constructor for class org.apache.hadoop.hbase.client.Delete
Create a Delete operation for the specified row and timestamp.
Delete(byte[], long) - Constructor for class org.apache.hadoop.hbase.client.Delete
Create a Delete operation for the specified row and timestamp.
Delete(byte[], long, NavigableMap<byte[], List<Cell>>) - Constructor for class org.apache.hadoop.hbase.client.Delete
Construct the Delete with user defined data.
Delete(Delete) - Constructor for class org.apache.hadoop.hbase.client.Delete
Create a Delete operation using another Delete as template.
DELETE - Enum constant in enum org.apache.hadoop.hbase.backup.BackupRestoreConstants.BackupCommand
 
DELETE - Enum constant in enum org.apache.hadoop.hbase.regionserver.Region.Operation
 
DELETE_BATCH_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
DELETE_FAMILY_BLOOM_META - Enum constant in enum org.apache.hadoop.hbase.io.hfile.BlockType
Delete Family Bloom filter metadata, version 2
DELETE_FAMILY_COUNT - Static variable in class org.apache.hadoop.hbase.regionserver.HStoreFile
Delete Family Count in FileInfo
DELETE_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
deleteAll(ByteBuffer, ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
 
deleteAll(List<Delete>) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
A simple version of batch delete.
deleteAllRow(ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
 
deleteAllRowTs(ByteBuffer, ByteBuffer, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
 
deleteAllTs(ByteBuffer, ByteBuffer, ByteBuffer, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
 
DeleteAsyncCallback() - Constructor for class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination.DeleteAsyncCallback
 
deleteBackups(String[]) - Method in interface org.apache.hadoop.hbase.backup.BackupAdmin
Delete backup image command
deleteBackupSet(String) - Method in interface org.apache.hadoop.hbase.backup.BackupAdmin
Delete backup set command
deleteBuffer - Variable in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanDeleteTracker
 
deleteCell - Variable in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanDeleteTracker
 
deleteChangedReaderObserver(ChangedReadersObserver) - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
deleteChildrenRecursively(ZKWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Delete all the children of the specified node but not the node itself.
deleteChildrenRecursivelyMultiOrSequential(ZKWatcher, boolean, String...) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Delete all the children of the specified node but not the node itself.
deleteColumn(TableName, byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
As of release 2.0.0. This will be removed in HBase 3.0.0. Use Admin.deleteColumnFamily(TableName, byte[])}.
deleteColumn(TableName, byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Deprecated.
Since 2.0. Will be removed in 3.0. Use Admin.deleteColumnFamily(TableName, byte[]) instead.
deleteColumn(TableName, byte[], long, long) - Method in class org.apache.hadoop.hbase.master.HMaster
 
deleteColumn(TableName, byte[], long, long) - Method in interface org.apache.hadoop.hbase.master.MasterServices
Delete a column from an existing table
deleteColumn(RpcController, MasterProtos.DeleteColumnRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
deleteColumn(RpcController, MasterProtos.DeleteColumnRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
 
DeleteColumn - Enum constant in enum org.apache.hadoop.hbase.Cell.Type
 
DeleteColumn - Enum constant in enum org.apache.hadoop.hbase.KeyValue.Type
 
deleteColumnFamily(TableName, byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
Delete a column family from a table.
deleteColumnFamily(TableName, byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Delete a column family from a table.
deleteColumnFamilyAsync(TableName, byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
Delete a column family from a table.
deleteColumnFamilyAsync(TableName, byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
DELETED - Enum constant in enum org.apache.hadoop.hbase.master.SplitLogManager.TerminationStatus
Deprecated.
 
deleteDirectory(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.CommonFSUtils
Delete if exists.
deleteFamily(String) - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
Remove the region family from disk, archiving the store files.
DeleteFamily - Enum constant in enum org.apache.hadoop.hbase.Cell.Type
 
DeleteFamily - Enum constant in enum org.apache.hadoop.hbase.KeyValue.Type
 
deleteFamilyBloomFilter - Variable in class org.apache.hadoop.hbase.regionserver.StoreFileReader
 
deleteFamilyFromFS(Path, RegionInfo, byte[]) - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
 
deleteFamilyFromFS(RegionInfo, byte[]) - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
 
DeleteFamilyVersion - Enum constant in enum org.apache.hadoop.hbase.Cell.Type
 
DeleteFamilyVersion - Enum constant in enum org.apache.hadoop.hbase.KeyValue.Type
 
deleteFavoredNodesForRegion(RegionInfo) - Method in class org.apache.hadoop.hbase.favored.FavoredNodesManager
 
deleteFavoredNodesForRegions(Collection<RegionInfo>) - Method in class org.apache.hadoop.hbase.favored.FavoredNodesManager
 
deleteIfEquals(ZKWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.MasterAddressTracker
delete the master znode if its content is same as the parameter
deleteLength - Variable in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanDeleteTracker
 
deleteMergeQualifiers(Connection, RegionInfo) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Deletes merge qualifiers for the specified merge region.
deleteMetaLocation(ZKWatcher) - Static method in class org.apache.hadoop.hbase.zookeeper.MetaTableLocator
Deletes the location of hbase:meta in ZooKeeper.
deleteMetaLocation(ZKWatcher, int) - Static method in class org.apache.hadoop.hbase.zookeeper.MetaTableLocator
 
deleteMyEphemeralNodeOnDisk() - Static method in class org.apache.hadoop.hbase.ZNodeClearer
delete the znode file
deleteNamespace(String) - Method in interface org.apache.hadoop.hbase.client.Admin
Delete an existing namespace.
deleteNamespace(String) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Delete an existing namespace.
deleteNamespace(String) - Method in class org.apache.hadoop.hbase.namespace.NamespaceAuditor
 
deleteNamespace(String, NonceKey, ProcedurePrepareLatch) - Method in interface org.apache.hadoop.hbase.master.ClusterSchema
Delete an existing Namespace.
deleteNamespace(RpcController, MasterProtos.DeleteNamespaceRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
deleteNamespace(RpcController, MasterProtos.DeleteNamespaceRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
 
deleteNamespaceAsync(String) - Method in interface org.apache.hadoop.hbase.client.Admin
Delete an existing namespace.
deleteNamespaceAsync(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
deleteNamespaceQuota(Connection, String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaUtil
 
deleteNoBody(byte[], UriInfo, HttpHeaders) - Method in class org.apache.hadoop.hbase.rest.NamespacesInstanceResource
Build a response for DELETE delete namespace.
deleteNode(ZKWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Delete the specified node.
deleteNode(ZKWatcher, String, int) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Delete the specified node with the specified version.
deleteNodeFailSilent(String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp
Returns a deleteNodeFailSilent ZKUtilOP
deleteNodeFailSilent(ZKWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Deletes the specified node.
deleteNodeRecursively(ZKWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Delete the specified node and all of it's children.
deleteNodeRecursivelyMultiOrSequential(ZKWatcher, boolean, String...) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Delete the specified node and its children.
deleteOffset - Variable in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanDeleteTracker
 
deleteRegionDir(Configuration, RegionInfo) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Delete the region directory if exists.
deleteRegionFromFileSystem(Configuration, FileSystem, Path, RegionInfo) - Static method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
Remove the region from the table directory, archiving the region's hfiles.
deleteRegionInfo(Connection, RegionInfo) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Deletes the specified region from META.
deleteRegionInfos(Connection, List<RegionInfo>) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Deletes the specified regions from META.
deleteRegionServerQuota(Connection, String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaUtil
 
deletes - Variable in class org.apache.hadoop.hbase.regionserver.querymatcher.CompactionScanQueryMatcher
Keeps track of deletes
DELETES - Enum constant in enum org.apache.hadoop.hbase.mapreduce.WALPlayer.Counter
Number of aggregated deletes
deleteShutdownHook(Runnable) - Static method in class org.apache.hadoop.hbase.util.ShutdownHookManager
 
deleteSnapshot(byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
Since 2.2.0. Will be removed in 3.0.0. Use Admin.deleteSnapshot(String) instead.
deleteSnapshot(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
deleteSnapshot(String) - Method in interface org.apache.hadoop.hbase.client.Admin
Delete an existing snapshot.
deleteSnapshot(String) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Delete an existing snapshot.
deleteSnapshot(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
deleteSnapshot(RpcController, MasterProtos.DeleteSnapshotRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
deleteSnapshot(RpcController, MasterProtos.DeleteSnapshotRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
Execute Delete Snapshot operation.
deleteSnapshots() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Delete all existing snapshots.
deleteSnapshots(String) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
since 2.0 version and will be removed in 3.0 version. Use Admin.deleteSnapshots(Pattern) instead.
deleteSnapshots(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
deleteSnapshots(Pattern) - Method in interface org.apache.hadoop.hbase.client.Admin
Delete existing snapshots whose names match the pattern passed.
deleteSnapshots(Pattern) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Delete existing snapshots whose names match the pattern passed.
deleteSnapshots(Pattern) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
deleteStoreFile() - Method in class org.apache.hadoop.hbase.regionserver.HStoreFile
Delete this file
deleteTable(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
 
deleteTable(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
Deletes a table.
deleteTable(TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Deletes a table.
deleteTable(TableName, long, long) - Method in class org.apache.hadoop.hbase.master.HMaster
 
deleteTable(TableName, long, long) - Method in interface org.apache.hadoop.hbase.master.MasterServices
Delete a table
deleteTable(RpcController, MasterProtos.DeleteTableRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
deleteTable(RpcController, MasterProtos.DeleteTableRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
 
deleteTableAsync(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
Deletes the table but does not block and wait for it to be completely removed.
deleteTableAsync(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
deleteTableDescriptors(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSTableDescriptors
 
deleteTableQuota(Connection, TableName) - Static method in class org.apache.hadoop.hbase.quotas.QuotaUtil
 
deleteTables(String) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
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)
deleteTables(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
deleteTables(Pattern) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
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)
deleteTables(Pattern) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
Delete tables matching the passed in pattern and wait on completion.
deleteTableSnapshots(String, String) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
since 2.0 version and will be removed in 3.0 version. Use Admin.deleteTableSnapshots(Pattern, Pattern) instead.
deleteTableSnapshots(String, String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
deleteTableSnapshots(Pattern) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Delete all existing snapshots matching the given table name pattern.
deleteTableSnapshots(Pattern, Pattern) - Method in interface org.apache.hadoop.hbase.client.Admin
Delete all existing snapshots matching the given table name regular expression and snapshot name regular expression.
deleteTableSnapshots(Pattern, Pattern) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Delete all existing snapshots matching the given table name regular expression and snapshot name regular expression.
deleteTableSnapshots(Pattern, Pattern) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
deleteTableSource(String) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableAggregateSource
Remove a table's source.
deleteTableSource(String) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableAggregateSourceImpl
 
deleteTableState(Connection, TableName) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Remove state for table from meta
deleteTask(String) - Method in interface org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination
Deprecated.
 
deleteTask(String) - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
 
deleteTimestamp - Variable in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanDeleteTracker
 
org.apache.hadoop.hbase.regionserver.querymatcher.DeleteTracker - Interface in org.apache.hadoop.hbase.regionserver.querymatcher
This interface is used for the tracking and enforcement of Deletes during the course of a Get or Scan operation.
org.apache.hadoop.hbase.regionserver.querymatcher.DeleteTracker.DeleteResult - Enum in org.apache.hadoop.hbase.regionserver.querymatcher
Returns codes for delete result.
deleteType - Variable in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanDeleteTracker
 
deleteUserQuota(Connection, String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaUtil
 
deleteUserQuota(Connection, String, String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaUtil
 
deleteUserQuota(Connection, String, TableName) - Static method in class org.apache.hadoop.hbase.quotas.QuotaUtil
 
DeleteVersionsNode() - Constructor for class org.apache.hadoop.hbase.regionserver.querymatcher.NewVersionBehaviorTracker.DeleteVersionsNode
 
DeleteVersionsNode(long, long) - Constructor for class org.apache.hadoop.hbase.regionserver.querymatcher.NewVersionBehaviorTracker.DeleteVersionsNode
 
deleteWALDir(ServerName) - Method in class org.apache.hadoop.hbase.master.SplitWALManager
 
deleteZooKeeper(TableName) - Method in class org.apache.hadoop.hbase.master.TableStateManager
Deprecated.
Since 2.0.0. To be removed in hbase-3.0.0.
org.apache.hadoop.hbase.zookeeper.DeletionListener - Class in org.apache.hadoop.hbase.zookeeper
A ZooKeeper watcher meant to detect deletions of ZNodes.
DeletionListener(ZKWatcher, String, CountDownLatch) - Constructor for class org.apache.hadoop.hbase.zookeeper.DeletionListener
Create a new instance of the deletion watcher.
delFamMap - Variable in class org.apache.hadoop.hbase.regionserver.querymatcher.NewVersionBehaviorTracker
 
org.apache.hadoop.hbase.regionserver.DelimitedKeyPrefixRegionSplitPolicy - Class in org.apache.hadoop.hbase.regionserver
Deprecated.
since 2.5.0 and will be removed in 4.0.0. Use RegionSplitRestriction, instead.
DelimitedKeyPrefixRegionSplitPolicy() - Constructor for class org.apache.hadoop.hbase.regionserver.DelimitedKeyPrefixRegionSplitPolicy
Deprecated.
 
org.apache.hadoop.hbase.regionserver.DelimitedKeyPrefixRegionSplitRestriction - Class in org.apache.hadoop.hbase.regionserver
A RegionSplitRestriction implementation that groups rows by a prefix of the row-key with a delimiter.
DelimitedKeyPrefixRegionSplitRestriction() - Constructor for class org.apache.hadoop.hbase.regionserver.DelimitedKeyPrefixRegionSplitRestriction
 
DELIMITER - Static variable in class org.apache.hadoop.hbase.HConstants
delimiter used between portions of a region name
DELIMITER - Static variable in class org.apache.hadoop.hbase.namequeues.WALEventTrackerTableAccessor
 
DELIMITER_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.DelimitedKeyPrefixRegionSplitPolicy
Deprecated.
 
DELIMITER_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.DelimitedKeyPrefixRegionSplitRestriction
 
org.apache.hadoop.hbase.thrift.DemoClient - Class in org.apache.hadoop.hbase.thrift
See the instructions under hbase-examples/README.txt
org.apache.hadoop.hbase.filter.DependentColumnFilter - Class in org.apache.hadoop.hbase.filter
A filter for adding inter-column timestamp matching Only cells with a correspondingly timestamped entry in the target column will be retained Not compatible with Scan.setBatch as operations need full rows for correct filtering
DependentColumnFilter(byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.filter.DependentColumnFilter
Constructor for DependentColumn filter.
DependentColumnFilter(byte[], byte[], boolean) - Constructor for class org.apache.hadoop.hbase.filter.DependentColumnFilter
Constructor for DependentColumn filter.
DependentColumnFilter(byte[], byte[], boolean, CompareOperator, ByteArrayComparable) - Constructor for class org.apache.hadoop.hbase.filter.DependentColumnFilter
Build a dependent column filter with value checking dependent column varies will be compared using the supplied compareOp and comparator, for usage of which refer to CompareFilter
DependentColumnFilter(byte[], byte[], boolean, CompareFilter.CompareOp, ByteArrayComparable) - Constructor for class org.apache.hadoop.hbase.filter.DependentColumnFilter
Deprecated.
Since 2.0.0. Will be removed in 3.0.0. Use DependentColumnFilter(byte[], byte[], boolean, CompareOperator, ByteArrayComparable) instead.
DEPRECATED_ALLOCATOR_POOL_ENABLED_KEY - Static variable in class org.apache.hadoop.hbase.io.ByteBuffAllocator
Deprecated.
since 2.3.0 and will be removed in 4.0.0. Use ByteBuffAllocator.ALLOCATOR_POOL_ENABLED_KEY instead.
DEPRECATED_MOB_CLEANER_PERIOD - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
 
dequeuedCall(int) - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
dequeuedCall(int) - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceImpl
 
deregister() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsUserSource
 
deregister() - Method in class org.apache.hadoop.hbase.regionserver.MetricsUserSourceImpl
 
deregister(MetricsRegionSource) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionAggregateSource
Remove a region's source.
deregister(MetricsRegionSource) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionAggregateSourceImpl
 
deregister(MetricsUserSource) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsUserAggregateSource
 
deregister(MetricsUserSource) - Method in class org.apache.hadoop.hbase.regionserver.MetricsUserAggregateSourceImpl
 
deregisterChildren(ConfigurationManager) - Method in interface org.apache.hadoop.hbase.conf.PropagatingConfigurationObserver
Needs to be called to deregister the children from the manager.
deregisterChildren(ConfigurationManager) - Method in class org.apache.hadoop.hbase.regionserver.CompactSplit
Needs to be called to deregister the children from the manager.
deregisterChildren(ConfigurationManager) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Needs to be called to deregister the children from the manager.
deregisterChildren(ConfigurationManager) - Method in class org.apache.hadoop.hbase.regionserver.HStore
Needs to be called to deregister the children from the manager.
deregisterChildren(ConfigurationManager) - Method in class org.apache.hadoop.hbase.regionserver.PrefetchExecutorNotifier
Needs to be called to deregister the children from the manager.
deregisterObserver(ConfigurationObserver) - Method in class org.apache.hadoop.hbase.conf.ConfigurationManager
Deregister an observer class
DESCENDING - Enum constant in enum org.apache.hadoop.hbase.util.Order
 
DESCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedBlob
 
DESCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedBlobVar
 
DESCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedFloat32
 
DESCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedFloat64
 
DESCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedInt16
 
DESCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedInt32
 
DESCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedInt64
 
DESCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedInt8
 
DESCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedNumeric
 
DESCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedString
 
DESCENDING - Static variable in class org.apache.hadoop.hbase.types.RawBytes
 
DESCENDING - Static variable in class org.apache.hadoop.hbase.types.RawString
 
descendingIterator() - Method in class org.apache.hadoop.hbase.regionserver.CellSet
 
descendingKeySet() - Method in class org.apache.hadoop.hbase.regionserver.CellFlatMap
 
descendingKeySet() - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
 
descendingMap() - Method in class org.apache.hadoop.hbase.regionserver.CellFlatMap
 
descendingMap() - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
 
descendingSet() - Method in class org.apache.hadoop.hbase.regionserver.CellSet
 
DESCRIBE - Enum constant in enum org.apache.hadoop.hbase.backup.BackupRestoreConstants.BackupCommand
 
DESCRIPTOR_VERSION - Static variable in class org.apache.hadoop.hbase.snapshot.SnapshotManifestV1
 
DESCRIPTOR_VERSION - Static variable in class org.apache.hadoop.hbase.snapshot.SnapshotManifestV2
 
org.apache.hadoop.hbase.exceptions.DeserializationException - Exception in org.apache.hadoop.hbase.exceptions
Failed deserialization.
DeserializationException() - Constructor for exception org.apache.hadoop.hbase.exceptions.DeserializationException
 
DeserializationException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.DeserializationException
 
DeserializationException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.exceptions.DeserializationException
 
DeserializationException(Throwable) - Constructor for exception org.apache.hadoop.hbase.exceptions.DeserializationException
 
deserialize(byte[]) - Static method in exception org.apache.hadoop.hbase.errorhandling.ForeignException
Takes a series of bytes and tries to generate an ForeignException instance for it.
deserialize(Cell) - Method in class org.apache.hadoop.hbase.mapreduce.CellSerialization.CellDeserializer
 
deserialize(ExtendedCell) - Method in class org.apache.hadoop.hbase.mapreduce.ExtendedCellSerialization.ExtendedCellDeserializer
 
deserialize(KeyValue) - Method in class org.apache.hadoop.hbase.mapreduce.KeyValueSerialization.KeyValueDeserializer
Deprecated.
 
deserialize(ByteBuff, ByteBuffAllocator) - Method in interface org.apache.hadoop.hbase.io.hfile.CacheableDeserializer
 
deserialize(ByteBuff, ByteBuffAllocator) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock.BlockDeserializer
 
deserializeAttributes(Map<String, byte[]>) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
Convert a map of byte array attributes to a more readable map of binary string representations
deserializeMobFileRefs(byte[]) - Static method in class org.apache.hadoop.hbase.mob.MobUtils
Deserialize the set of referenced mob hfiles from store file metadata.
deserializeStateData(ProcedureStateSerializer) - Method in class org.apache.hadoop.hbase.regionserver.storefiletracker.ModifyColumnFamilyStoreFileTrackerProcedure
 
deserializeStateData(ProcedureStateSerializer) - Method in class org.apache.hadoop.hbase.regionserver.storefiletracker.ModifyStoreFileTrackerProcedure
 
designatedFile(String) - Method in class org.apache.hadoop.hbase.util.RegionMover.RegionMoverBuilder
Set the designated file.
destroy() - Method in class org.apache.hadoop.hbase.http.AdminAuthorizedFilter
 
destroy() - Method in class org.apache.hadoop.hbase.http.ClickjackingPreventionFilter
 
destroy() - Method in class org.apache.hadoop.hbase.http.HttpServer.QuotingInputFilter
 
destroy() - Method in class org.apache.hadoop.hbase.http.lib.StaticUserWebFilter.StaticUserFilter
 
destroy() - Method in class org.apache.hadoop.hbase.http.NoCacheFilter
 
destroy() - Method in class org.apache.hadoop.hbase.http.SecurityHeadersFilter
 
destroyDirectByteBuffer(ByteBuffer) - Static method in class org.apache.hadoop.hbase.util.DirectMemoryUtils
DirectByteBuffers are garbage collected by using a phantom reference and a reference queue.
detail(String) - Method in interface org.apache.hadoop.hbase.util.HbckErrorReporter
Deprecated.
 
determineRSGroupInfoForTable(TableName) - Method in interface org.apache.hadoop.hbase.rsgroup.RSGroupInfoManager
Determine RSGroupInfo for the given table.
determineTTLFromFamily(ColumnFamilyDescriptor) - Static method in class org.apache.hadoop.hbase.regionserver.HStore
Returns TTL in seconds of the specified family
DFS_REPLICATION - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
DFS_REPLICATION - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
org.apache.hadoop.hbase.io.util.Dictionary - Interface in org.apache.hadoop.hbase.io.util
Dictionary interface Dictionary indexes should be either bytes or shorts, only positive.
DICTIONARY_MAX_SIZE_KEY - Static variable in class org.apache.hadoop.hbase.io.compress.DictionaryCache
 
org.apache.hadoop.hbase.io.compress.DictionaryCache - Class in org.apache.hadoop.hbase.io.compress
A utility class for managing compressor/decompressor dictionary loading and caching of load results.
DIFF - Enum constant in enum org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
 
DiffCompressionState() - Constructor for class org.apache.hadoop.hbase.io.encoding.DiffKeyDeltaEncoder.DiffCompressionState
 
DIFFERENTCELLVALUES - Enum constant in enum org.apache.hadoop.hbase.mapreduce.SyncTable.SyncMapper.Counter
 
org.apache.hadoop.hbase.io.encoding.DiffKeyDeltaEncoder - Class in org.apache.hadoop.hbase.io.encoding
Compress using: - store size of common prefix - save column family once, it is same within HFile - use integer compression for key, value and prefix (7-bit encoding) - use bits to avoid duplication key length, value length and type if it same as previous - store in 3 bits length of timestamp field - allow diff in timestamp instead of actual value Format: - 1 byte: flag - 1-5 bytes: key length (only if FLAG_SAME_KEY_LENGTH is not set in flag) - 1-5 bytes: value length (only if FLAG_SAME_VALUE_LENGTH is not set in flag) - 1-5 bytes: prefix length - ...
DiffKeyDeltaEncoder() - Constructor for class org.apache.hadoop.hbase.io.encoding.DiffKeyDeltaEncoder
 
org.apache.hadoop.hbase.io.encoding.DiffKeyDeltaEncoder.DiffCompressionState - Class in org.apache.hadoop.hbase.io.encoding
 
org.apache.hadoop.hbase.io.encoding.DiffKeyDeltaEncoder.DiffSeekerState - Class in org.apache.hadoop.hbase.io.encoding
 
DiffSeekerState(ObjectIntPair<ByteBuffer>, boolean) - Constructor for class org.apache.hadoop.hbase.io.encoding.DiffKeyDeltaEncoder.DiffSeekerState
 
DIGEST - Enum constant in enum org.apache.hadoop.hbase.security.AuthMethod
 
directBufferAddress(ByteBuffer) - Static method in class org.apache.hadoop.hbase.util.UnsafeAccess
 
org.apache.hadoop.hbase.util.DirectMemoryUtils - Class in org.apache.hadoop.hbase.util
Utilities for interacting with and monitoring DirectByteBuffer allocations.
DirectMemoryUtils() - Constructor for class org.apache.hadoop.hbase.util.DirectMemoryUtils
 
DirFilter(FileSystem) - Constructor for class org.apache.hadoop.hbase.util.FSUtils.DirFilter
 
disable() - Method in class org.apache.hadoop.hbase.quotas.policies.DefaultViolationPolicyEnforcement
 
disable() - Method in class org.apache.hadoop.hbase.quotas.policies.DisableTableViolationPolicyEnforcement
 
disable() - Method in class org.apache.hadoop.hbase.quotas.policies.MissingSnapshotViolationPolicyEnforcement
 
disable() - Method in class org.apache.hadoop.hbase.quotas.policies.NoInsertsViolationPolicyEnforcement
 
disable() - Method in class org.apache.hadoop.hbase.quotas.policies.NoWritesCompactionsViolationPolicyEnforcement
 
disable() - Method in class org.apache.hadoop.hbase.quotas.policies.NoWritesViolationPolicyEnforcement
 
disable() - Method in interface org.apache.hadoop.hbase.quotas.SpaceViolationPolicyEnforcement
Disables this policy.
DISABLE - Enum constant in enum org.apache.hadoop.hbase.quotas.SpaceViolationPolicy
Disables the table(s).
DISABLED - Enum constant in enum org.apache.hadoop.hbase.client.SnapshotType
 
DISABLED - Enum constant in enum org.apache.hadoop.hbase.client.TableState.State
 
DISABLED - Enum constant in enum org.apache.hadoop.hbase.replication.ReplicationPeer.PeerState
 
DISABLED - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
Disabled cache configuration
DISABLED_ZNODE_BYTES - Static variable in class org.apache.hadoop.hbase.replication.ZKReplicationPeerStorage
 
org.apache.hadoop.hbase.regionserver.DisabledRegionSplitPolicy - Class in org.apache.hadoop.hbase.regionserver
A RegionSplitPolicy that disables region splits.
DisabledRegionSplitPolicy() - Constructor for class org.apache.hadoop.hbase.regionserver.DisabledRegionSplitPolicy
 
DisabledServlet() - Constructor for class org.apache.hadoop.hbase.http.ProfileServlet.DisabledServlet
 
disableJSON() - Method in class org.apache.hadoop.hbase.wal.WALPrettyPrinter
turns JSON output off, and turns on "pretty strings" for human consumption
disablePeer(String) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Deprecated.
use Admin.disableReplicationPeer(String) instead
disableReplicationPeer(String) - Method in interface org.apache.hadoop.hbase.client.Admin
Stop the replication stream to the specified peer.
disableReplicationPeer(String) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Stop the replication stream to the specified peer
disableReplicationPeer(String) - Method in class org.apache.hadoop.hbase.master.HMaster
 
disableReplicationPeer(String) - Method in interface org.apache.hadoop.hbase.master.MasterServices
Stop the replication stream to the specified peer
disableReplicationPeer(RpcController, ReplicationProtos.DisableReplicationPeerRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
disableReplicationPeer(RpcController, ReplicationProtos.DisableReplicationPeerRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
 
disableReplicationPeerAsync(String) - Method in interface org.apache.hadoop.hbase.client.Admin
Disable a replication peer but does not block and wait for it.
disableReplicationPeerAsync(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
disableTable(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
 
disableTable(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
Disable table and wait on completion.
disableTable(TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Disable a table.
disableTable(TableName, long, long) - Method in class org.apache.hadoop.hbase.master.HMaster
 
disableTable(TableName, long, long) - Method in interface org.apache.hadoop.hbase.master.MasterServices
Disable an existing table
disableTable(RpcController, MasterProtos.DisableTableRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
disableTable(RpcController, MasterProtos.DisableTableRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
 
disableTableAsync(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
Disable the table but does not block and wait for it to be completely disabled.
disableTableAsync(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
disableTableIfNotDisabled(Connection, TableName) - Static method in class org.apache.hadoop.hbase.quotas.QuotaUtil
Method to disable a table, if not already disabled.
disableTableRep(TableName) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Deprecated.
use Admin.disableTableReplication(TableName) instead
disableTableReplication(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
Disable a table's replication switch.
disableTableReplication(TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Disable a table's replication switch.
disableTableReplication(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
disableTables(String) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
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)
disableTables(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
disableTables(Pattern) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
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)
disableTables(Pattern) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
org.apache.hadoop.hbase.quotas.policies.DisableTableViolationPolicyEnforcement - Class in org.apache.hadoop.hbase.quotas.policies
A SpaceViolationPolicyEnforcement which disables the table.
DisableTableViolationPolicyEnforcement() - Constructor for class org.apache.hadoop.hbase.quotas.policies.DisableTableViolationPolicyEnforcement
 
disableValues() - Method in class org.apache.hadoop.hbase.wal.WALPrettyPrinter
turns value output off
disableViolationPolicyEnforcement(TableName) - Method in class org.apache.hadoop.hbase.quotas.RegionServerSpaceQuotaManager
Disables enforcement on any violation policy on the given tableName.
disableWriteBufferPeriodicFlush() - Method in interface org.apache.hadoop.hbase.client.AsyncBufferedMutatorBuilder
Disable the periodical flush, i.e, set the timeout to 0.
disableWriteBufferPeriodicFlush() - Method in interface org.apache.hadoop.hbase.client.BufferedMutator
Disable periodic flushing of the write buffer.
disableZkAndClientLoggers() - Static method in class org.apache.hadoop.hbase.logging.Log4jUtils
Disables Zk- and HBase client logging
DISABLING - Enum constant in enum org.apache.hadoop.hbase.client.TableState.State
 
DISALLOWED_TABLE_NAME - Static variable in class org.apache.hadoop.hbase.TableName
One globally disallowed name
disconnect() - Method in class org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint
 
disconnectSince() - Method in interface org.apache.hadoop.hbase.ipc.RpcCallContext
Check if the caller who made this IPC call has disconnected.
disconnectSince() - Method in class org.apache.hadoop.hbase.ipc.ServerCall
 
dispatch(CallRunner) - Method in class org.apache.hadoop.hbase.ipc.BalancedQueueRpcExecutor
 
dispatch(CallRunner) - Method in class org.apache.hadoop.hbase.ipc.DelegatingRpcScheduler
 
dispatch(CallRunner) - Method in class org.apache.hadoop.hbase.ipc.FastPathBalancedQueueRpcExecutor
 
dispatch(CallRunner) - Method in class org.apache.hadoop.hbase.ipc.FastPathRWQueueRpcExecutor
 
dispatch(CallRunner) - Method in class org.apache.hadoop.hbase.ipc.FifoRpcScheduler
 
dispatch(CallRunner) - Method in class org.apache.hadoop.hbase.ipc.MasterFifoRpcScheduler
 
dispatch(CallRunner) - Method in class org.apache.hadoop.hbase.ipc.RpcExecutor
Add the request to the executor queue
dispatch(CallRunner) - Method in class org.apache.hadoop.hbase.ipc.RpcScheduler
Dispatches an RPC request asynchronously.
dispatch(CallRunner) - Method in class org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
 
dispatch(CallRunner) - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
 
dispatchTo(boolean, boolean, CallRunner) - Method in class org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
 
DISPLAY_KEYS_KEY - Static variable in class org.apache.hadoop.hbase.client.RegionInfoDisplay
 
dispose() - Method in class org.apache.hadoop.hbase.security.AbstractHBaseSaslRpcClient
Release resources used by wrapped saslClient
dispose() - Method in class org.apache.hadoop.hbase.security.HBaseSaslRpcServer
Release resources used by wrapped saslServer
dispose(T) - Method in class org.apache.hadoop.hbase.http.jersey.SupplierFactoryAdapter
 
divideForAvg(S, Long) - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
used for computing average of <S> data values.
org.apache.hadoop.hbase.util.DNS - Class in org.apache.hadoop.hbase.util
Wrapper around Hadoop's DNS class to hide reflection.
org.apache.hadoop.hbase.util.DNS.ServerType - Enum in org.apache.hadoop.hbase.util
 
DO_NOTHING_COUNTER_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSource
 
DO_NOTHING_COUNTER_NAME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSource
 
doAdd(MutableSegment, Cell, MemStoreSizing) - Method in class org.apache.hadoop.hbase.regionserver.AbstractMemStore
 
doAppend(WALProvider.AsyncWriter, FSWALEntry) - Method in class org.apache.hadoop.hbase.regionserver.wal.AsyncFSWAL
 
doAppend(WALProvider.Writer, FSWALEntry) - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
 
doAppend(W, FSWALEntry) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
 
doAsEnabled - Variable in class org.apache.hadoop.hbase.thrift.ThriftServer
 
doAsUser - Static variable in class org.apache.hadoop.hbase.thrift.HttpDoAsClient
 
doBatchWithCallback(List<? extends Row>, Object[], Batch.Callback<R>, ClusterConnection, ExecutorService, TableName, Map<String, byte[]>) - Static method in class org.apache.hadoop.hbase.client.HTable
 
doCall() - Method in class org.apache.hadoop.hbase.client.AsyncAdminRequestRetryingCaller
 
doCall() - Method in class org.apache.hadoop.hbase.client.AsyncMasterRequestRpcRetryingCaller
 
doCall() - Method in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCaller
 
doCall() - Method in class org.apache.hadoop.hbase.client.AsyncServerRequestRpcRetryingCaller
 
doCall() - Method in class org.apache.hadoop.hbase.regionserver.FlushRegionCallable
 
doCall() - Method in class org.apache.hadoop.hbase.regionserver.SnapshotRegionCallable
 
doCall() - Method in class org.apache.hadoop.hbase.regionserver.SnapshotVerifyCallable
 
doCall() - Method in class org.apache.hadoop.hbase.regionserver.SplitWALCallable
 
doCheckLogLowReplication() - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
 
doCheckLogLowReplication() - Method in class org.apache.hadoop.hbase.regionserver.wal.AsyncFSWAL
 
doCheckLogLowReplication() - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
Returns true if number of replicas for the WAL is lower than threshold
doCheckSlowSync() - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
Returns true if we exceeded the slow sync roll threshold over the last check interval
doClearSnapShot() - Method in class org.apache.hadoop.hbase.regionserver.AbstractMemStore
 
doCompaction(CompactionRequestImpl, Collection<HStoreFile>, User, long, List<Path>) - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
doesNamespaceExist(String) - Method in class org.apache.hadoop.hbase.master.TableNamespaceManager
 
doFilter(FilterChain, HttpServletRequest, HttpServletResponse) - Method in class org.apache.hadoop.hbase.http.ProxyUserAuthenticationFilter
 
doFilter(ServletRequest, ServletResponse, FilterChain) - Method in class org.apache.hadoop.hbase.http.AdminAuthorizedFilter
 
doFilter(ServletRequest, ServletResponse, FilterChain) - Method in class org.apache.hadoop.hbase.http.ClickjackingPreventionFilter
 
doFilter(ServletRequest, ServletResponse, FilterChain) - Method in class org.apache.hadoop.hbase.http.HttpServer.QuotingInputFilter
 
doFilter(ServletRequest, ServletResponse, FilterChain) - Method in class org.apache.hadoop.hbase.http.lib.StaticUserWebFilter.StaticUserFilter
 
doFilter(ServletRequest, ServletResponse, FilterChain) - Method in class org.apache.hadoop.hbase.http.NoCacheFilter
 
doFilter(ServletRequest, ServletResponse, FilterChain) - Method in class org.apache.hadoop.hbase.http.SecurityHeadersFilter
 
doGet(HttpServletRequest, HttpServletResponse) - Method in class org.apache.hadoop.hbase.http.AdminAuthorizedServlet
 
doGet(HttpServletRequest, HttpServletResponse) - Method in class org.apache.hadoop.hbase.http.conf.ConfServlet
 
doGet(HttpServletRequest, HttpServletResponse) - Method in class org.apache.hadoop.hbase.http.HttpServer.StackServlet
 
doGet(HttpServletRequest, HttpServletResponse) - Method in class org.apache.hadoop.hbase.http.jmx.JMXJsonServlet
Process a GET request for the specified resource.
doGet(HttpServletRequest, HttpServletResponse) - Method in class org.apache.hadoop.hbase.http.log.LogLevel.Servlet
 
doGet(HttpServletRequest, HttpServletResponse) - Method in class org.apache.hadoop.hbase.http.ProfileOutputServlet
 
doGet(HttpServletRequest, HttpServletResponse) - Method in class org.apache.hadoop.hbase.http.ProfileServlet.DisabledServlet
 
doGet(HttpServletRequest, HttpServletResponse) - Method in class org.apache.hadoop.hbase.http.ProfileServlet
 
doGet(HttpServletRequest, HttpServletResponse) - Method in class org.apache.hadoop.hbase.http.prometheus.PrometheusHadoopServlet
 
doGet(HttpServletRequest, HttpServletResponse) - Method in class org.apache.hadoop.hbase.regionserver.http.RSDumpServlet
 
doGet(HttpServletRequest, HttpServletResponse) - Method in class org.apache.hadoop.hbase.regionserver.http.RSStatusServlet
 
doGet(HttpServletRequest, HttpServletResponse) - Method in class org.apache.hadoop.hbase.rest.RESTDumpServlet
 
doGet(Connection, List<Get>) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
doGet(Connection, Get) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
doGet(ClientProtos.GetRequest) - Method in class org.apache.hadoop.hbase.client.ClientServiceCallable
 
doInit(Configuration) - Method in class org.apache.hadoop.hbase.wal.AbstractFSWALProvider
 
doInit(Configuration) - Method in class org.apache.hadoop.hbase.wal.AsyncFSWALProvider
 
doInit(Configuration) - Method in class org.apache.hadoop.hbase.wal.FSHLogProvider
 
doLoadColumnFamiliesOnDemand() - Method in class org.apache.hadoop.hbase.client.ImmutableScan
 
doLoadColumnFamiliesOnDemand() - Method in class org.apache.hadoop.hbase.client.Query
Get the logical value indicating whether on-demand CF loading should be allowed.
doMain(String[]) - Method in class org.apache.hadoop.hbase.util.ServerCommandLine
Parse and run the given command line.
domainNamePointerToHostName(String) - Static method in class org.apache.hadoop.hbase.util.Strings
Given a PTR string generated via reverse DNS lookup, return everything except the trailing period.
doMutate(ClientProtos.MutateRequest) - Method in class org.apache.hadoop.hbase.client.ClientServiceCallable
 
done - Variable in class org.apache.hadoop.hbase.master.SplitLogManager.TaskBatch
Deprecated.
 
done() - Method in class org.apache.hadoop.hbase.ipc.ServerCall
Call is done.
done() - Method in interface org.apache.hadoop.hbase.regionserver.querymatcher.ColumnTracker
Returns true when done.
done() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ExplicitColumnTracker
Done when there are no more columns to match against.
done() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.NewVersionBehaviorTracker
 
done() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanWildcardColumnTracker
We can never know a-priori if we are done, so always return false.
Done(ServerName) - Constructor for class org.apache.hadoop.hbase.SplitLogTask.Done
Deprecated.
 
DONE - Enum constant in enum org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination.TaskFinisher.Status
task completed successfully
DONE - Enum constant in enum org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher.MatchCode
Do not include, return current result
DONE - Enum constant in enum org.apache.hadoop.hbase.regionserver.SplitLogWorker.TaskExecutor.Status
Deprecated.
 
DONE_SCAN - Enum constant in enum org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher.MatchCode
Done with scan, thanks to the row filter.
doneBulkLoad(byte[], String) - Method in interface org.apache.hadoop.hbase.regionserver.HRegion.BulkLoadListener
Called after a successful HFile load
doneWithColumn(Cell) - Method in interface org.apache.hadoop.hbase.regionserver.querymatcher.ColumnTracker
This method is used to inform the column tracker that we are done with this column.
doneWithColumn(Cell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ExplicitColumnTracker
 
org.apache.hadoop.hbase.DoNotRetryIOException - Exception in org.apache.hadoop.hbase
Subclass if exception is not meant to be retried: e.g.
DoNotRetryIOException() - Constructor for exception org.apache.hadoop.hbase.DoNotRetryIOException
 
DoNotRetryIOException(String) - Constructor for exception org.apache.hadoop.hbase.DoNotRetryIOException
 
DoNotRetryIOException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.DoNotRetryIOException
 
DoNotRetryIOException(Throwable) - Constructor for exception org.apache.hadoop.hbase.DoNotRetryIOException
 
org.apache.hadoop.hbase.client.DoNotRetryRegionException - Exception in org.apache.hadoop.hbase.client
Similar to RegionException, but disables retries.
DoNotRetryRegionException() - Constructor for exception org.apache.hadoop.hbase.client.DoNotRetryRegionException
 
DoNotRetryRegionException(String) - Constructor for exception org.apache.hadoop.hbase.client.DoNotRetryRegionException
 
DoNotRetryRegionException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.client.DoNotRetryRegionException
 
DoNotRetryRegionException(Throwable) - Constructor for exception org.apache.hadoop.hbase.client.DoNotRetryRegionException
 
DONT_FILL_HEADER - Static variable in class org.apache.hadoop.hbase.io.hfile.HFileBlock
 
doPost(HttpServletRequest, HttpServletResponse) - Method in class org.apache.hadoop.hbase.thrift.ThriftHttpServlet
 
doRealSeek(KeyValueScanner, Cell, boolean) - Static method in class org.apache.hadoop.hbase.regionserver.NonLazyKeyValueScanner
 
doRegionCompactionPrep() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Do preparation for pending compaction.
doReplaceWriter(Path, Path, WALProvider.AsyncWriter) - Method in class org.apache.hadoop.hbase.regionserver.wal.AsyncFSWAL
 
doReplaceWriter(Path, Path, WALProvider.Writer) - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
 
doReplaceWriter(Path, Path, W) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
Notice that you need to clear the AbstractFSWAL.rollRequested flag in this method, as the new writer will begin to work before returning from this method.
doResizeIfNecessary() - Method in class org.apache.hadoop.hbase.hbtop.screen.AbstractScreenView
 
doResizeIfNecessary() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenView
 
doResizeIfNecessary() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.batch.BatchTerminal
 
doResizeIfNecessary() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.TerminalImpl
 
doResizeIfNecessary() - Method in interface org.apache.hadoop.hbase.hbtop.terminal.Terminal
 
doSetup(Mapper.Context) - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
Handles common parameter initialization that a subclass might want to leverage.
doSetup(Mapper.Context) - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterTextMapper
Handles common parameter initialization that a subclass might want to leverage.
doSetup(Reducer.Context, Configuration) - Method in class org.apache.hadoop.hbase.mapreduce.TextSortReducer
Handles common parameter initialization that a subclass might want to leverage.
doShutdown() - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
 
doShutdown() - Method in class org.apache.hadoop.hbase.regionserver.wal.AsyncFSWAL
 
doShutdown() - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
 
doSmokeTest(FileSystem, Path, String) - Static method in class org.apache.hadoop.hbase.util.CompressionTest
 
doStart() - Method in class org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint
 
doStart() - Method in class org.apache.hadoop.hbase.replication.VerifyWALEntriesReplicationEndpoint
 
doStaticMain(String[]) - Method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
Call this from the concrete tool class's main function.
doStop() - Method in class org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint
 
doStop() - Method in class org.apache.hadoop.hbase.replication.VerifyWALEntriesReplicationEndpoint
 
doSync(boolean) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
 
doSync(boolean) - Method in class org.apache.hadoop.hbase.regionserver.wal.AsyncFSWAL
 
doSync(boolean) - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
 
doSync(long, boolean) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
 
doSync(long, boolean) - Method in class org.apache.hadoop.hbase.regionserver.wal.AsyncFSWAL
 
doSync(long, boolean) - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
 
doubleEquals(Object) - Method in class org.apache.hadoop.hbase.hbtop.RecordFilter.FilterBuilder
 
doubleEquals(FieldValue) - Method in class org.apache.hadoop.hbase.hbtop.RecordFilter.FilterBuilder
 
doWork() - Method in class org.apache.hadoop.hbase.backup.BackupDriver
 
doWork() - Method in class org.apache.hadoop.hbase.backup.RestoreDriver
 
doWork() - Method in class org.apache.hadoop.hbase.mapreduce.RowCounter
 
doWork() - Method in class org.apache.hadoop.hbase.snapshot.CreateSnapshot
 
doWork() - Method in class org.apache.hadoop.hbase.snapshot.ExportSnapshot
Execute the export snapshot by copying the snapshot metadata, hfiles and wals.
doWork() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo
 
doWork() - Method in class org.apache.hadoop.hbase.tool.coprocessor.CoprocessorValidator
 
doWork() - Method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
The "main function" of the tool
doWork() - Method in class org.apache.hadoop.hbase.util.RegionMover
 
DRAINING_REGION_SERVER_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
 
DRAINING_REGION_SERVER_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
 
org.apache.hadoop.hbase.master.DrainingServerTracker - Class in org.apache.hadoop.hbase.master
Tracks the list of draining region servers via ZK.
DrainingServerTracker(ZKWatcher, Abortable, ServerManager) - Constructor for class org.apache.hadoop.hbase.master.DrainingServerTracker
 
drainingZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZNodePaths
 
drainInputStreamToBuffer(InputStream) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
Deprecated.
Copy from the InputStream to a new heap ByteBuffer until the InputStream is exhausted.
drainTo(Collection<? super E>) - Method in class org.apache.hadoop.hbase.util.BoundedPriorityBlockingQueue
 
drainTo(Collection<? super E>, int) - Method in class org.apache.hadoop.hbase.util.BoundedPriorityBlockingQueue
 
drainTo(Collection<? super Runnable>) - Method in class org.apache.hadoop.hbase.thrift.CallQueue
 
drainTo(Collection<? super Runnable>, int) - Method in class org.apache.hadoop.hbase.thrift.CallQueue
 
drainTo(Collection<? super CallRunner>) - Method in class org.apache.hadoop.hbase.ipc.AdaptiveLifoCoDelCallQueue
 
drainTo(Collection<? super CallRunner>, int) - Method in class org.apache.hadoop.hbase.ipc.AdaptiveLifoCoDelCallQueue
 
drillDown() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenPresenter
 
drillDown(Record) - Method in class org.apache.hadoop.hbase.hbtop.mode.ClientModeStrategy
 
drillDown(Record) - Method in enum org.apache.hadoop.hbase.hbtop.mode.Mode
 
drillDown(Record) - Method in class org.apache.hadoop.hbase.hbtop.mode.NamespaceModeStrategy
 
drillDown(Record) - Method in class org.apache.hadoop.hbase.hbtop.mode.RegionModeStrategy
 
drillDown(Record) - Method in class org.apache.hadoop.hbase.hbtop.mode.RegionServerModeStrategy
 
drillDown(Record) - Method in class org.apache.hadoop.hbase.hbtop.mode.TableModeStrategy
 
drillDown(Record) - Method in class org.apache.hadoop.hbase.hbtop.mode.UserModeStrategy
 
drillDown(Record) - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenModel
 
org.apache.hadoop.hbase.hbtop.mode.DrillDownInfo - Class in org.apache.hadoop.hbase.hbtop.mode
Information about drilling down.
DrillDownInfo(Mode, List<RecordFilter>) - Constructor for class org.apache.hadoop.hbase.hbtop.mode.DrillDownInfo
 
org.apache.hadoop.hbase.mapred.Driver - Class in org.apache.hadoop.hbase.mapred
Driver for hbase mapreduce jobs.
org.apache.hadoop.hbase.mapreduce.Driver - Class in org.apache.hadoop.hbase.mapreduce
Driver for hbase mapreduce jobs.
Driver() - Constructor for class org.apache.hadoop.hbase.mapred.Driver
 
drop() - Method in class org.apache.hadoop.hbase.ipc.CallRunner
When we want to drop this call because of server is overloaded.
DROP_BEHIND_CACHE_COMPACTION_DEFAULT - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
 
DROP_BEHIND_CACHE_COMPACTION_KEY - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
 
org.apache.hadoop.hbase.regionserver.querymatcher.DropDeletesCompactionScanQueryMatcher - Class in org.apache.hadoop.hbase.regionserver.querymatcher
A query matcher for compaction which can drop delete markers.
DropDeletesCompactionScanQueryMatcher(ScanInfo, DeleteTracker, ColumnTracker, long, long, long, long) - Constructor for class org.apache.hadoop.hbase.regionserver.querymatcher.DropDeletesCompactionScanQueryMatcher
 
dropDependentColumn - Variable in class org.apache.hadoop.hbase.filter.DependentColumnFilter
 
dropDependentColumn() - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
Returns true if we should drop the dependent column, false otherwise
org.apache.hadoop.hbase.DroppedSnapshotException - Exception in org.apache.hadoop.hbase
Thrown during flush if the possibility snapshot content was not properly persisted into store files.
DroppedSnapshotException() - Constructor for exception org.apache.hadoop.hbase.DroppedSnapshotException
 
DroppedSnapshotException(String) - Constructor for exception org.apache.hadoop.hbase.DroppedSnapshotException
 
DroppedSnapshotException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.DroppedSnapshotException
DroppedSnapshotException with cause
DRY_RUN_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv
 
DUD - Static variable in interface org.apache.hadoop.hbase.regionserver.MemStoreSizing
 
DUMMY - Static variable in interface org.apache.hadoop.hbase.regionserver.FlushLifeCycleTracker
 
dump(ZKWatcher) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKDump
 
dump(Logger) - Method in class org.apache.hadoop.hbase.regionserver.AbstractMemStore
 
dumpAllBeans() - Static method in class org.apache.hadoop.hbase.util.JSONBean
Dump out all registered mbeans as json on System.out.
dumpBeanToString(String) - Static method in class org.apache.hadoop.hbase.util.JSONMetricUtil
Returns a subset of mbeans defined by qry.
dumpCallQueues(HRegionServer, PrintWriter) - Static method in class org.apache.hadoop.hbase.regionserver.http.RSDumpServlet
 
dumpMetrics() - Static method in class org.apache.hadoop.hbase.regionserver.DumpRegionServerMetrics
Dump out a subset of regionserver mbeans only, not all of them, as json on System.out.
dumpQueue() - Method in class org.apache.hadoop.hbase.regionserver.CompactSplit
 
dumpQueue() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreFlusher
 
dumpQueue(HRegionServer, PrintWriter) - Static method in class org.apache.hadoop.hbase.regionserver.http.RSDumpServlet
 
org.apache.hadoop.hbase.regionserver.DumpRegionServerMetrics - Class in org.apache.hadoop.hbase.regionserver
Utility for doing JSON and MBeans.
dumpRowLocks(PrintWriter) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
Used by RSDumpServlet to generate debugging information.
dumpTailOfLogs(PrintWriter, long) - Static method in class org.apache.hadoop.hbase.util.LogMonitoring
 
DUPE_ENDKEYS - Enum constant in enum org.apache.hadoop.hbase.util.HbckErrorReporter.ERROR_CODE
Deprecated.
 
DUPE_STARTKEYS - Enum constant in enum org.apache.hadoop.hbase.util.HbckErrorReporter.ERROR_CODE
Deprecated.
 
duplicate() - Method in class org.apache.hadoop.hbase.nio.ByteBuff
Returns an ByteBuff which is a duplicate version of this ByteBuff.
duplicate() - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
Returns an MBB which is a duplicate version of this MBB.
duplicate() - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
 
durability - Variable in class org.apache.hadoop.hbase.client.Mutation
 
org.apache.hadoop.hbase.client.Durability - Enum in org.apache.hadoop.hbase.client
Enum describing the durability guarantees for tables and Mutations Note that the items must be sorted in order of increasing durability
DURABILITY - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
Durability setting for the table.
DURABILITY - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
 
org.apache.hadoop.hbase.util.DynamicClassLoader - Class in org.apache.hadoop.hbase.util
This is a class loader that can load classes dynamically from new jar files under a configured folder.
DynamicClassLoader(Configuration, ClassLoader) - Constructor for class org.apache.hadoop.hbase.util.DynamicClassLoader
Creates a DynamicClassLoader that can load classes dynamically from jar files under a specific folder.

E

E - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for 'E'
EAGER - Enum constant in enum org.apache.hadoop.hbase.MemoryCompactionPolicy
In addition to compacting the index representation as the basic policy, eager policy eliminates duplication while the data is still in memory (much like the on-disk compaction does after the data is flushed to disk).
org.apache.hadoop.hbase.regionserver.EagerMemStoreCompactionStrategy - Class in org.apache.hadoop.hbase.regionserver
 
EagerMemStoreCompactionStrategy(Configuration, String) - Constructor for class org.apache.hadoop.hbase.regionserver.EagerMemStoreCompactionStrategy
 
EARLIEST_PUT_TS - Static variable in class org.apache.hadoop.hbase.regionserver.HStoreFile
Key for timestamp of earliest-put in metadata
earliestPutTs - Variable in class org.apache.hadoop.hbase.regionserver.querymatcher.DropDeletesCompactionScanQueryMatcher
Oldest put in any of the involved store files Used to decide whether it is ok to delete family delete marker of this store keeps deleted KVs.
editRegion(RegionInfo) - Method in interface org.apache.hadoop.hbase.util.ModifyRegionUtils.RegionEditTask
 
editRegions(ThreadPoolExecutor, Collection<RegionInfo>, ModifyRegionUtils.RegionEditTask) - Static method in class org.apache.hadoop.hbase.util.ModifyRegionUtils
Execute the task on the specified set of regions.
element() - Method in class org.apache.hadoop.hbase.ipc.AdaptiveLifoCoDelCallQueue
 
element() - Method in class org.apache.hadoop.hbase.thrift.CallQueue
 
EMPTY_BATCHES - Enum constant in enum org.apache.hadoop.hbase.mapreduce.SyncTable.SyncMapper.Counter
 
EMPTY_BYTE_ARRAY - Static variable in class org.apache.hadoop.hbase.HConstants
An empty byte array instance.
EMPTY_BYTE_BUFFER - Static variable in class org.apache.hadoop.hbase.HConstants
 
EMPTY_END_ROW - Static variable in class org.apache.hadoop.hbase.HConstants
Last row in a table.
EMPTY_HEADER_ARRAY - Static variable in class org.apache.hadoop.hbase.rest.client.Client
 
EMPTY_META_CELL - Enum constant in enum org.apache.hadoop.hbase.util.HbckErrorReporter.ERROR_CODE
Deprecated.
 
EMPTY_REGION_INFO_REGIONS - Static variable in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
 
EMPTY_REGION_INFO_REGIONS_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
 
EMPTY_RESULT - Static variable in class org.apache.hadoop.hbase.client.Result
 
EMPTY_RESULT_ARRAY - Static variable in class org.apache.hadoop.hbase.client.BatchScanResultCache
 
EMPTY_SERVER_LIST - Static variable in class org.apache.hadoop.hbase.ServerName
 
EMPTY_SERVERLOAD - Static variable in class org.apache.hadoop.hbase.ServerLoad
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use ServerMetricsBuilder.of(ServerName) instead.
EMPTY_START_ROW - Static variable in class org.apache.hadoop.hbase.HConstants
Used by scanners, etc when they want to start at the beginning of a region
EMPTY_STRING - Static variable in class org.apache.hadoop.hbase.HConstants
An empty string instance.
EMPTY_STRING - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
 
EMPTY_UUIDS - Static variable in interface org.apache.hadoop.hbase.wal.WALKey
Unmodifiable empty list of UUIDs.
EMPTY_VALUE_ON_MOBCELL_MISS - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
 
EMPTY_WALKEYIMPL - Static variable in class org.apache.hadoop.hbase.wal.WALKeyImpl
 
org.apache.hadoop.hbase.ipc.EmptyServiceNameException - Exception in org.apache.hadoop.hbase.ipc
 
EmptyServiceNameException() - Constructor for exception org.apache.hadoop.hbase.ipc.EmptyServiceNameException
 
org.apache.hadoop.hbase.zookeeper.EmptyWatcher - Class in org.apache.hadoop.hbase.zookeeper
An empty ZooKeeper watcher
enable() - Method in class org.apache.hadoop.hbase.quotas.policies.DefaultViolationPolicyEnforcement
 
enable() - Method in class org.apache.hadoop.hbase.quotas.policies.DisableTableViolationPolicyEnforcement
 
enable() - Method in class org.apache.hadoop.hbase.quotas.policies.MissingSnapshotViolationPolicyEnforcement
 
enable() - Method in class org.apache.hadoop.hbase.quotas.policies.NoInsertsViolationPolicyEnforcement
 
enable() - Method in class org.apache.hadoop.hbase.quotas.policies.NoWritesCompactionsViolationPolicyEnforcement
 
enable() - Method in class org.apache.hadoop.hbase.quotas.policies.NoWritesViolationPolicyEnforcement
 
enable() - Method in interface org.apache.hadoop.hbase.quotas.SpaceViolationPolicyEnforcement
Enables this policy.
ENABLE_BACKUP - Static variable in interface org.apache.hadoop.hbase.backup.BackupRestoreConstants
 
ENABLE_CLIENT_BACKPRESSURE - Static variable in class org.apache.hadoop.hbase.HConstants
Config key for if the server should send backpressure and if the client should listen to that backpressure from the server
ENABLE_DATA_FILE_UMASK - Static variable in class org.apache.hadoop.hbase.HConstants
Enable file permission modification from standard hbase
ENABLE_TABLE_LATENCIES_METRICS_DEFAULT - Static variable in class org.apache.hadoop.hbase.regionserver.metrics.MetricsTableRequests
 
ENABLE_TABLE_LATENCIES_METRICS_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.metrics.MetricsTableRequests
 
ENABLE_TABLE_QUERY_METER_METRICS_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.metrics.MetricsTableRequests
 
ENABLE_TABLE_QUERY_METER_METRICS_KEY_DEFAULT - Static variable in class org.apache.hadoop.hbase.regionserver.metrics.MetricsTableRequests
 
ENABLE_WAL_COMPRESSION - Static variable in class org.apache.hadoop.hbase.HConstants
Configuration name of WAL Compression
ENABLE_WAL_ENCRYPTION - Static variable in class org.apache.hadoop.hbase.HConstants
Configuration key for enabling WAL encryption, a boolean
ENABLE_WAL_TAGS_COMPRESSION - Static variable in class org.apache.hadoop.hbase.regionserver.wal.CompressionContext
 
ENABLE_WAL_VALUE_COMPRESSION - Static variable in class org.apache.hadoop.hbase.regionserver.wal.CompressionContext
 
enableCacheOnWrite() - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
Enable cache on write including: cacheDataOnWrite cacheIndexesOnWrite cacheBloomsOnWrite
enableCatalogJanitor(boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
Since 2.0.0. Will be removed in 3.0.0. Use Admin.catalogJanitorSwitch(boolean)} instead.
enableCatalogJanitor(RpcController, MasterProtos.EnableCatalogJanitorRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
enableCatalogJanitor(RpcController, MasterProtos.EnableCatalogJanitorRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
 
enableCertFileReloading(Configuration, AtomicReference<FileChangeWatcher>, AtomicReference<FileChangeWatcher>, Runnable) - Static method in class org.apache.hadoop.hbase.io.crypto.tls.X509Util
Enable certificate file reloading by creating FileWatchers for keystore and truststore.
ENABLED - Enum constant in enum org.apache.hadoop.hbase.client.TableState.State
 
ENABLED - Enum constant in enum org.apache.hadoop.hbase.replication.ReplicationPeer.PeerState
 
ENABLED_ZNODE_BYTES - Static variable in class org.apache.hadoop.hbase.replication.ZKReplicationPeerStorage
 
enableDebug(Class<?>) - Static method in class org.apache.hadoop.hbase.logging.Log4jUtils
Switches the logger for the given class to DEBUG level.
enableJSON() - Method in class org.apache.hadoop.hbase.wal.WALPrettyPrinter
turns JSON output on
enablePeer(String) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Deprecated.
use Admin.enableReplicationPeer(String) instead
enableReplicationPeer(String) - Method in interface org.apache.hadoop.hbase.client.Admin
Restart the replication stream to the specified peer.
enableReplicationPeer(String) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Restart the replication stream to the specified peer
enableReplicationPeer(String) - Method in class org.apache.hadoop.hbase.master.HMaster
 
enableReplicationPeer(String) - Method in interface org.apache.hadoop.hbase.master.MasterServices
Restart the replication stream to the specified peer
enableReplicationPeer(RpcController, ReplicationProtos.EnableReplicationPeerRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
enableReplicationPeer(RpcController, ReplicationProtos.EnableReplicationPeerRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
 
enableReplicationPeerAsync(String) - Method in interface org.apache.hadoop.hbase.client.Admin
Enable a replication peer but does not block and wait for it.
enableReplicationPeerAsync(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
enableTable(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
 
enableTable(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
Enable a table.
enableTable(TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Enable a table.
enableTable(TableName, long, long) - Method in class org.apache.hadoop.hbase.master.HMaster
 
enableTable(TableName, long, long) - Method in interface org.apache.hadoop.hbase.master.MasterServices
Enable an existing table
enableTable(RpcController, MasterProtos.EnableTableRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
enableTable(RpcController, MasterProtos.EnableTableRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
 
enableTableAsync(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
Enable the table but does not block and wait for it to be completely enabled.
enableTableAsync(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
enableTableIfNotEnabled(Connection, TableName) - Static method in class org.apache.hadoop.hbase.quotas.QuotaUtil
Method to enable a table, if not already enabled.
enableTableRep(TableName) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Deprecated.
use Admin.enableTableReplication(TableName) instead
enableTableReplication(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
Enable a table's replication switch.
enableTableReplication(TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Enable a table's replication switch.
enableTableReplication(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
enableTables(String) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
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)
enableTables(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
enableTables(Pattern) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
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)
enableTables(Pattern) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
enableTestingStats() - Method in class org.apache.hadoop.hbase.io.hfile.CompoundBloomFilter
 
enableValues() - Method in class org.apache.hadoop.hbase.wal.WALPrettyPrinter
turns value output on
ENABLING - Enum constant in enum org.apache.hadoop.hbase.client.TableState.State
 
ENC_SEPARATOR - Static variable in interface org.apache.hadoop.hbase.client.RegionInfo
Separator used to demarcate the encodedName in a region name in the new format.
encode(Cell, HFileBlockEncodingContext, DataOutputStream) - Method in class org.apache.hadoop.hbase.io.encoding.CopyKeyDataBlockEncoder
 
encode(Cell, HFileBlockEncodingContext, DataOutputStream) - Method in interface org.apache.hadoop.hbase.io.encoding.DataBlockEncoder
Encodes a KeyValue.
encode(Cell, HFileBlockEncodingContext, DataOutputStream) - Method in class org.apache.hadoop.hbase.io.encoding.RowIndexCodecV1
 
encode(Cell, HFileBlockEncodingContext, DataOutputStream) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoder
Encodes a KeyValue.
encode(Cell, HFileBlockEncodingContext, DataOutputStream) - Method in class org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoderImpl
 
encode(Cell, HFileBlockEncodingContext, DataOutputStream) - Method in class org.apache.hadoop.hbase.io.hfile.NoOpDataBlockEncoder
 
encode(BlockIndexChunk, boolean, DataOutput) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileIndexBlockEncoder
 
encode(BlockIndexChunk, boolean, DataOutput) - Method in class org.apache.hadoop.hbase.io.hfile.HFileIndexBlockEncoderImpl
 
encode(BlockIndexChunk, boolean, DataOutput) - Method in class org.apache.hadoop.hbase.io.hfile.NoOpIndexBlockEncoder
 
encode(PositionedByteRange, byte[]) - Method in class org.apache.hadoop.hbase.types.OrderedBlob
 
encode(PositionedByteRange, byte[]) - Method in class org.apache.hadoop.hbase.types.OrderedBlobVar
 
encode(PositionedByteRange, byte[]) - Method in class org.apache.hadoop.hbase.types.RawBytes
 
encode(PositionedByteRange, byte[], int, int) - Method in class org.apache.hadoop.hbase.types.OrderedBlob
Write a subset of val to dst.
encode(PositionedByteRange, byte[], int, int) - Method in class org.apache.hadoop.hbase.types.OrderedBlobVar
Write a subset of val to buff.
encode(PositionedByteRange, byte[], int, int) - Method in class org.apache.hadoop.hbase.types.RawBytes
Write val into dst, respecting voff and vlen.
encode(PositionedByteRange, byte[], int, int) - Method in class org.apache.hadoop.hbase.types.RawBytesFixedLength
Write val into buff, respecting offset and length.
encode(PositionedByteRange, byte[], int, int) - Method in class org.apache.hadoop.hbase.types.RawBytesTerminated
Write val into dst, respecting offset and length.
encode(PositionedByteRange, Byte) - Method in class org.apache.hadoop.hbase.types.OrderedInt8
 
encode(PositionedByteRange, Byte) - Method in class org.apache.hadoop.hbase.types.RawByte
 
encode(PositionedByteRange, Double) - Method in class org.apache.hadoop.hbase.types.OrderedFloat64
 
encode(PositionedByteRange, Double) - Method in class org.apache.hadoop.hbase.types.RawDouble
 
encode(PositionedByteRange, Float) - Method in class org.apache.hadoop.hbase.types.OrderedFloat32
 
encode(PositionedByteRange, Float) - Method in class org.apache.hadoop.hbase.types.RawFloat
 
encode(PositionedByteRange, Integer) - Method in class org.apache.hadoop.hbase.types.OrderedInt32
 
encode(PositionedByteRange, Integer) - Method in class org.apache.hadoop.hbase.types.RawInteger
 
encode(PositionedByteRange, Long) - Method in class org.apache.hadoop.hbase.types.OrderedInt64
 
encode(PositionedByteRange, Long) - Method in class org.apache.hadoop.hbase.types.RawLong
 
encode(PositionedByteRange, Number) - Method in class org.apache.hadoop.hbase.types.OrderedNumeric
 
encode(PositionedByteRange, Object[]) - Method in class org.apache.hadoop.hbase.types.Struct
 
encode(PositionedByteRange, Short) - Method in class org.apache.hadoop.hbase.types.OrderedInt16
 
encode(PositionedByteRange, Short) - Method in class org.apache.hadoop.hbase.types.RawShort
 
encode(PositionedByteRange, String) - Method in class org.apache.hadoop.hbase.types.OrderedString
 
encode(PositionedByteRange, String) - Method in class org.apache.hadoop.hbase.types.RawString
 
encode(PositionedByteRange, CellProtos.Cell) - Method in class org.apache.hadoop.hbase.types.PBCell
 
encode(PositionedByteRange, T) - Method in interface org.apache.hadoop.hbase.types.DataType
Write instance val into buffer dst.
encode(PositionedByteRange, T) - Method in class org.apache.hadoop.hbase.types.FixedLengthWrapper
 
encode(PositionedByteRange, T) - Method in class org.apache.hadoop.hbase.types.TerminatedWrapper
Write instance val into buffer dst.
encode(ChannelHandlerContext, ByteBuf, ByteBuf) - Method in class org.apache.hadoop.hbase.security.SaslWrapHandler
 
ENCODE_ON_DISK - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
encodeBlobCopy(PositionedByteRange, byte[], int, int, Order) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Encode a Blob value as a byte-for-byte copy.
encodeBlobCopy(PositionedByteRange, byte[], Order) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Encode a Blob value as a byte-for-byte copy.
encodeBlobVar(PositionedByteRange, byte[], int, int, Order) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Encode a Blob value using a modified varint encoding scheme.
encodeBlobVar(PositionedByteRange, byte[], Order) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Encode a blob value using a modified varint encoding scheme.
encodeByte(byte[], int, byte) - Method in class org.apache.hadoop.hbase.types.RawByte
Write instance val into buffer buff.
encodeByte(PositionedByteRange, byte) - Method in class org.apache.hadoop.hbase.types.OrderedInt8
Write instance val into buffer dst.
ENCODED_DATA - Enum constant in enum org.apache.hadoop.hbase.io.hfile.BlockType
An encoded data block (e.g.
ENCODED_REGION_NAME_REGEX - Static variable in class org.apache.hadoop.hbase.client.RegionInfoBuilder
A non-capture group so that this can be embedded.
ENCODED_REGION_NAME_REGEX - Static variable in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
A non-capture group so that this can be embedded.
encodeData() - Method in class org.apache.hadoop.hbase.io.encoding.EncodedDataBlock
Do the encoding, but do not cache the encoded data.
encodedClass() - Method in interface org.apache.hadoop.hbase.types.DataType
Inform consumers over what type this DataType operates.
encodedClass() - Method in class org.apache.hadoop.hbase.types.FixedLengthWrapper
 
encodedClass() - Method in class org.apache.hadoop.hbase.types.OrderedBlob
 
encodedClass() - Method in class org.apache.hadoop.hbase.types.OrderedBlobVar
 
encodedClass() - Method in class org.apache.hadoop.hbase.types.OrderedFloat32
 
encodedClass() - Method in class org.apache.hadoop.hbase.types.OrderedFloat64
 
encodedClass() - Method in class org.apache.hadoop.hbase.types.OrderedInt16
 
encodedClass() - Method in class org.apache.hadoop.hbase.types.OrderedInt32
 
encodedClass() - Method in class org.apache.hadoop.hbase.types.OrderedInt64
 
encodedClass() - Method in class org.apache.hadoop.hbase.types.OrderedInt8
 
encodedClass() - Method in class org.apache.hadoop.hbase.types.OrderedNumeric
 
encodedClass() - Method in class org.apache.hadoop.hbase.types.OrderedString
 
encodedClass() - Method in class org.apache.hadoop.hbase.types.PBCell
 
encodedClass() - Method in class org.apache.hadoop.hbase.types.RawByte
 
encodedClass() - Method in class org.apache.hadoop.hbase.types.RawBytes
 
encodedClass() - Method in class org.apache.hadoop.hbase.types.RawDouble
 
encodedClass() - Method in class org.apache.hadoop.hbase.types.RawFloat
 
encodedClass() - Method in class org.apache.hadoop.hbase.types.RawInteger
 
encodedClass() - Method in class org.apache.hadoop.hbase.types.RawLong
 
encodedClass() - Method in class org.apache.hadoop.hbase.types.RawShort
 
encodedClass() - Method in class org.apache.hadoop.hbase.types.RawString
 
encodedClass() - Method in class org.apache.hadoop.hbase.types.Struct
 
encodedClass() - Method in class org.apache.hadoop.hbase.types.TerminatedWrapper
 
encodedClass() - Method in class org.apache.hadoop.hbase.types.Union2
 
org.apache.hadoop.hbase.io.encoding.EncodedDataBlock - Class in org.apache.hadoop.hbase.io.encoding
Encapsulates a data block compressed using a particular encoding algorithm.
EncodedDataBlock(Configuration, DataBlockEncoder, DataBlockEncoding, byte[], HFileContext) - Constructor for class org.apache.hadoop.hbase.io.encoding.EncodedDataBlock
Create a buffer which will be encoded using dataBlockEncoder.
encodedDataSizeWritten - Variable in class org.apache.hadoop.hbase.io.encoding.EncodingState
 
encodedLength(byte[]) - Method in class org.apache.hadoop.hbase.types.OrderedBlob
 
encodedLength(byte[]) - Method in class org.apache.hadoop.hbase.types.OrderedBlobVar
 
encodedLength(byte[]) - Method in class org.apache.hadoop.hbase.types.RawBytes
 
encodedLength(Byte) - Method in class org.apache.hadoop.hbase.types.OrderedInt8
 
encodedLength(Byte) - Method in class org.apache.hadoop.hbase.types.RawByte
 
encodedLength(Double) - Method in class org.apache.hadoop.hbase.types.OrderedFloat64
 
encodedLength(Double) - Method in class org.apache.hadoop.hbase.types.RawDouble
 
encodedLength(Float) - Method in class org.apache.hadoop.hbase.types.OrderedFloat32
 
encodedLength(Float) - Method in class org.apache.hadoop.hbase.types.RawFloat
 
encodedLength(Integer) - Method in class org.apache.hadoop.hbase.types.OrderedInt32
 
encodedLength(Integer) - Method in class org.apache.hadoop.hbase.types.RawInteger
 
encodedLength(Long) - Method in class org.apache.hadoop.hbase.types.OrderedInt64
 
encodedLength(Long) - Method in class org.apache.hadoop.hbase.types.RawLong
 
encodedLength(Number) - Method in class org.apache.hadoop.hbase.types.OrderedNumeric
 
encodedLength(Object[]) - Method in class org.apache.hadoop.hbase.types.Struct
 
encodedLength(Short) - Method in class org.apache.hadoop.hbase.types.OrderedInt16
 
encodedLength(Short) - Method in class org.apache.hadoop.hbase.types.RawShort
 
encodedLength(String) - Method in class org.apache.hadoop.hbase.types.OrderedString
 
encodedLength(String) - Method in class org.apache.hadoop.hbase.types.RawString
 
encodedLength(T) - Method in interface org.apache.hadoop.hbase.types.DataType
Inform consumers how long the encoded byte[] will be.
encodedLength(T) - Method in class org.apache.hadoop.hbase.types.FixedLengthWrapper
 
encodedLength(T) - Method in class org.apache.hadoop.hbase.types.PBType
Deprecated.
 
encodedLength(T) - Method in class org.apache.hadoop.hbase.types.TerminatedWrapper
 
encodeDouble(byte[], int, double) - Method in class org.apache.hadoop.hbase.types.RawDouble
Write instance val into buffer buff.
encodeDouble(PositionedByteRange, double) - Method in class org.apache.hadoop.hbase.types.OrderedFloat64
Write instance val into buffer dst.
encodeDouble(PositionedByteRange, double) - Method in class org.apache.hadoop.hbase.types.OrderedNumeric
Write instance val into buffer dst.
EncodedScanner(HFile.Reader, boolean, boolean, boolean, HFileContext, Configuration) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.EncodedScanner
 
encodeFloat(byte[], int, float) - Method in class org.apache.hadoop.hbase.types.RawFloat
Write instance val into buffer buff.
encodeFloat(PositionedByteRange, float) - Method in class org.apache.hadoop.hbase.types.OrderedFloat32
Write instance val into buffer buff.
encodeFloat32(PositionedByteRange, float, Order) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Encode a 32-bit floating point value using the fixed-length encoding.
encodeFloat64(PositionedByteRange, double, Order) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Encode a 64-bit floating point value using the fixed-length encoding.
encodeIdentifier(byte[]) - Static method in class org.apache.hadoop.hbase.security.SaslUtil
 
encodeInt(byte[], int, int) - Method in class org.apache.hadoop.hbase.types.RawInteger
Write instance val into buffer buff.
encodeInt(PositionedByteRange, int) - Method in class org.apache.hadoop.hbase.types.OrderedInt32
Write instance val into buffer dst.
encodeInt16(PositionedByteRange, short, Order) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Encode an int16 value using the fixed-length encoding.
encodeInt32(PositionedByteRange, int, Order) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Encode an int32 value using the fixed-length encoding.
encodeInt64(PositionedByteRange, long, Order) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Encode an int64 value using the fixed-length encoding.
encodeInt8(PositionedByteRange, byte, Order) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Encode an int8 value using the fixed-length encoding.
encodeLong(byte[], int, long) - Method in class org.apache.hadoop.hbase.types.RawLong
Write instance val into buffer buff.
encodeLong(PositionedByteRange, long) - Method in class org.apache.hadoop.hbase.types.OrderedInt64
Write instance val into buffer dst.
encodeLong(PositionedByteRange, long) - Method in class org.apache.hadoop.hbase.types.OrderedNumeric
Write instance val into buffer dst.
encodeNull(PositionedByteRange, Order) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Encode a null value.
encodeNumeric(PositionedByteRange, double, Order) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Encode a numerical value using the variable-length encoding.
encodeNumeric(PositionedByteRange, long, Order) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Encode a numerical value using the variable-length encoding.
encodeNumeric(PositionedByteRange, BigDecimal, Order) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Encode a numerical value using the variable-length encoding.
encodePassword(byte[]) - Static method in class org.apache.hadoop.hbase.security.SaslUtil
 
org.apache.hadoop.hbase.io.encoding.EncoderBufferTooSmallException - Exception in org.apache.hadoop.hbase.io.encoding
Internal error which indicates a bug in a data block encoding algorithm.
EncoderBufferTooSmallException(String) - Constructor for exception org.apache.hadoop.hbase.io.encoding.EncoderBufferTooSmallException
 
encodeRegionName(byte[]) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
Returns the encodedName
encodeRegionName(byte[]) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionInfo.encodeRegionName(byte[]).
encodeShort(byte[], int, short) - Method in class org.apache.hadoop.hbase.types.RawShort
Write instance val into buffer buff.
encodeShort(PositionedByteRange, short) - Method in class org.apache.hadoop.hbase.types.OrderedInt16
Write instance val into buffer dst.
encodeString(PositionedByteRange, String, Order) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
Encode a String value.
org.apache.hadoop.hbase.io.encoding.EncodingState - Class in org.apache.hadoop.hbase.io.encoding
Keeps track of the encoding state.
EncodingState() - Constructor for class org.apache.hadoop.hbase.io.encoding.EncodingState
 
encrypt(OutputStream, byte[], int, int, Encryption.Context, byte[]) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
Encrypt a block of plaintext
encrypt(OutputStream, byte[], int, int, Encryptor) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
Encrypt a block of plaintext
encrypt(OutputStream, InputStream, Encryption.Context, byte[]) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
Encrypt a stream of plaintext given a context and IV
encrypt(OutputStream, InputStream, Encryptor) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
Encrypt a stream of plaintext given an encryptor
org.apache.hadoop.hbase.io.crypto.Encryption - Class in org.apache.hadoop.hbase.io.crypto
A facade for encryption algorithms and related support.
ENCRYPTION - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
ENCRYPTION - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
ENCRYPTION_KEY - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
ENCRYPTION_KEY - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
org.apache.hadoop.hbase.io.crypto.Encryption.Context - Class in org.apache.hadoop.hbase.io.crypto
Crypto context
org.apache.hadoop.hbase.util.EncryptionTest - Class in org.apache.hadoop.hbase.util
 
org.apache.hadoop.hbase.security.EncryptionUtil - Class in org.apache.hadoop.hbase.security
Some static utility methods for encryption uses in hbase-client.
encryptor - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractProtobufLogWriter
 
org.apache.hadoop.hbase.io.crypto.Encryptor - Interface in org.apache.hadoop.hbase.io.crypto
Encryptors apply a cipher to an OutputStream to produce ciphertext.
encryptWithSubjectKey(OutputStream, InputStream, String, Configuration, Cipher, byte[]) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
Encrypts a block of plaintext with the symmetric key resolved for the given subject
end() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.InputModeScreenPresenter
 
end() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenPresenter
 
End - Enum constant in enum org.apache.hadoop.hbase.hbtop.terminal.KeyPress.Type
 
END - Enum constant in enum org.apache.hadoop.hbase.client.RequestController.ReturnCode
No more row can be included.
END - Static variable in class org.apache.hadoop.hbase.mapreduce.SimpleTotalOrderPartitioner
Deprecated.
since 0.90.0
END_TIME_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.WALInputFormat
 
endBlockEncoding(HFileBlockEncodingContext, DataOutputStream, byte[]) - Method in class org.apache.hadoop.hbase.io.encoding.CopyKeyDataBlockEncoder
 
endBlockEncoding(HFileBlockEncodingContext, DataOutputStream, byte[]) - Method in interface org.apache.hadoop.hbase.io.encoding.DataBlockEncoder
Ends encoding for a block of KeyValues.
endBlockEncoding(HFileBlockEncodingContext, DataOutputStream, byte[]) - Method in class org.apache.hadoop.hbase.io.encoding.RowIndexCodecV1
 
endBlockEncoding(HFileBlockEncodingContext, DataOutputStream, byte[], BlockType) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoder
Ends encoding for a block of KeyValues.
endBlockEncoding(HFileBlockEncodingContext, DataOutputStream, byte[], BlockType) - Method in class org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoderImpl
 
endBlockEncoding(HFileBlockEncodingContext, DataOutputStream, byte[], BlockType) - Method in class org.apache.hadoop.hbase.io.hfile.NoOpDataBlockEncoder
 
endOfLine() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.batch.BatchTerminalPrinter
 
endOfLine() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.Cell
 
endOfLine() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.TerminalPrinterImpl
 
endOfLine() - Method in interface org.apache.hadoop.hbase.hbtop.terminal.TerminalPrinter
 
endOfLine(int, int) - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.ScreenBuffer
 
endOperation(long, long, boolean) - Method in class org.apache.hadoop.hbase.regionserver.ServerNonceManager
Ends the operation started by startOperation.
endPersistentOutput() - Method in class org.apache.hadoop.hbase.wal.WALPrettyPrinter
ends output of a single, persistent list.
org.apache.hadoop.hbase.coprocessor.EndpointObserver - Interface in org.apache.hadoop.hbase.coprocessor
Coprocessors implement this interface to observe and mediate endpoint invocations on a region.
endTask(SplitLogTask, LongAdder, SplitLogWorkerCoordination.SplitTaskDetails) - Method in interface org.apache.hadoop.hbase.coordination.SplitLogWorkerCoordination
Deprecated.
Notify coordination engine that splitting task has completed.
endTask(SplitLogTask, LongAdder, SplitLogWorkerCoordination.SplitTaskDetails) - Method in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination
endTask() can fail and the only way to recover out of it is for the SplitLogManager to timeout the task node.
enforceSeek() - Method in interface org.apache.hadoop.hbase.regionserver.KeyValueScanner
Does the real seek operation in case it was skipped by seekToRowCol(KeyValue, boolean) (TODO: Whats this?).
enforceSeek() - Method in class org.apache.hadoop.hbase.regionserver.NonLazyKeyValueScanner
 
enforceSeek() - Method in class org.apache.hadoop.hbase.regionserver.SegmentScanner
This function should be never called on scanners that always do real seek operations (i.e.
enforceSeek() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
 
enforceViolationPolicy(TableName, SpaceQuotaSnapshot) - Method in class org.apache.hadoop.hbase.quotas.RegionServerSpaceQuotaManager
Enforces the given violationPolicy on the given table in this RegionServer.
enoughStatistics() - Method in class org.apache.hadoop.hbase.util.WindowMovingAverage
Check if there are enough statistics.
ENSEMBLE_TABLE_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
The name of the ensemble table
ensureConnectedZooKeeper(ZooKeeper, int) - Static method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperHelper
Ensure passed zookeeper is connected.
ensureKeyValue(Cell) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
Deprecated.
without any replacement.
ensureKeyValues(List<Cell>) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
Deprecated.
EnsureKvEncoder(OutputStream) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.WALCellCodec.EnsureKvEncoder
 
ensureSingleLevel() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexWriter
 
ensureSpace(ByteBuffer, int) - Static method in class org.apache.hadoop.hbase.io.encoding.CopyKeyDataBlockEncoder
Asserts that there is at least the given amount of unfilled space remaining in the given buffer.
Enter - Enum constant in enum org.apache.hadoop.hbase.hbtop.terminal.KeyPress.Type
 
org.apache.hadoop.hbase.client.locking.EntityLock - Class in org.apache.hadoop.hbase.client.locking
Lock for HBase Entity either a Table, a Namespace, or Regions.
org.apache.hadoop.hbase.client.locking.EntityLock.LockHeartbeatWorker - Class in org.apache.hadoop.hbase.client.locking
 
entry(Field, Object) - Static method in class org.apache.hadoop.hbase.hbtop.Record
 
entry(Field, FieldValue) - Static method in class org.apache.hadoop.hbase.hbtop.Record
 
Entry() - Constructor for class org.apache.hadoop.hbase.client.SingleResponse.Entry
 
Entry() - Constructor for class org.apache.hadoop.hbase.wal.WAL.Entry
 
Entry(WALKeyImpl, WALEdit) - Constructor for class org.apache.hadoop.hbase.wal.WAL.Entry
Constructor for both params
entryBuffers - Variable in class org.apache.hadoop.hbase.wal.OutputSink
 
org.apache.hadoop.hbase.wal.EntryBuffers - Class in org.apache.hadoop.hbase.wal
Class which accumulates edits and separates them into a buffer per region while simultaneously accounting RAM usage.
EntryBuffers(WALSplitter.PipelineController, long) - Constructor for class org.apache.hadoop.hbase.wal.EntryBuffers
 
org.apache.hadoop.hbase.wal.EntryBuffers.RegionEntryBuffer - Class in org.apache.hadoop.hbase.wal
A buffer of some number of edits for a given region.
entryCount - Variable in class org.apache.hadoop.hbase.io.hfile.HFileWriterImpl
Total # of key/value entries, i.e.
entrySet() - Method in class org.apache.hadoop.hbase.hbtop.Record
 
entrySet() - Method in class org.apache.hadoop.hbase.io.hfile.HFileInfo
 
entrySet() - Method in class org.apache.hadoop.hbase.regionserver.CellFlatMap
 
entrySet() - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
 
org.apache.hadoop.hbase.util.EnvironmentEdge - Interface in org.apache.hadoop.hbase.util
Has some basic interaction with the environment.
org.apache.hadoop.hbase.util.EnvironmentEdgeManager - Class in org.apache.hadoop.hbase.util
Manages a singleton instance of the environment edge.
eof() - Method in enum org.apache.hadoop.hbase.wal.WALTailingReader.State
 
EOF_AND_RESET - Enum constant in enum org.apache.hadoop.hbase.wal.WALTailingReader.State
This means we reach the EOF and the upper layer need to reset to see if there is more data.
EOF_AND_RESET_COMPRESSION - Enum constant in enum org.apache.hadoop.hbase.wal.WALTailingReader.State
Mostly the same with the above WALTailingReader.State.EOF_AND_RESET, the difference is that here we also mess up the compression dictionary when reading data, so the upper layer should also clear the compression context when reseting, which means when calling resetTo method, we need to skip to the position instead of just seek to, which will impact performance.
EOF_WITH_TRAILER - Enum constant in enum org.apache.hadoop.hbase.wal.WALTailingReader.State
This means the WAL file has a trailer and we have reached it, which means we have finished reading this file normally
equal(Object) - Method in class org.apache.hadoop.hbase.hbtop.RecordFilter.FilterBuilder
 
equal(FieldValue) - Method in class org.apache.hadoop.hbase.hbtop.RecordFilter.FilterBuilder
 
EQUAL - Enum constant in enum org.apache.hadoop.hbase.CompareOperator
equals
EQUAL - Enum constant in enum org.apache.hadoop.hbase.filter.CompareFilter.CompareOp
Deprecated.
equals
EQUAL_TO - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for equal to (=)
EQUAL_TO_ARRAY - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
EQUAL_TO Array
EQUAL_TO_BUFFER - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
 
equals(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
Lexicographically determine the equality of two arrays.
equals(byte[], int, int, byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
Lexicographically determine the equality of two arrays.
equals(byte[], ByteBuffer) - Static method in class org.apache.hadoop.hbase.util.Bytes
Lexicographically determine the equality of two byte[], one as ByteBuffer.
equals(Object) - Method in class org.apache.hadoop.hbase.backup.BackupInfo
 
equals(Object) - Method in class org.apache.hadoop.hbase.ByteBufferKeyValue
Needed doing 'contains' on List.
equals(Object) - Method in class org.apache.hadoop.hbase.client.Action
 
equals(Object) - Method in class org.apache.hadoop.hbase.client.CheckAndMutate
 
equals(Object) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
 
equals(Object) - Method in class org.apache.hadoop.hbase.client.Get
 
equals(Object) - Method in class org.apache.hadoop.hbase.client.Increment
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use Row.COMPARATOR instead
equals(Object) - Method in class org.apache.hadoop.hbase.client.LogQueryFilter
Deprecated.
 
equals(Object) - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord
 
equals(Object) - Method in class org.apache.hadoop.hbase.client.RegionCoprocessorServiceExec
 
equals(Object) - Method in class org.apache.hadoop.hbase.client.RegionStatesCount
 
equals(Object) - Method in class org.apache.hadoop.hbase.client.RowMutations
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. No replacement
equals(Object) - Method in class org.apache.hadoop.hbase.client.SlowLogParams
 
equals(Object) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
Compare the contents of the descriptor with another one passed as a parameter.
equals(Object) - Method in class org.apache.hadoop.hbase.client.TableState
 
equals(Object) - Method in class org.apache.hadoop.hbase.ClusterStatus
Deprecated.
 
equals(Object) - Method in class org.apache.hadoop.hbase.favored.FavoredNodesPlan
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.BigDecimalComparator
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.BinaryComponentComparator
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.ColumnPrefixFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.ColumnValueFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.CompareFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.FamilyFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.FilterList
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.FilterListWithAND
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.FilterListWithOR
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.FirstKeyValueMatchingQualifiersFilter
Deprecated.
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.FuzzyRowFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.InclusiveStopFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.RowRange
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.NullComparator
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.PageFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.PrefixFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.QualifierFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.RandomRowFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.RowFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.SkipFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.TimestampsFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.ValueFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.hbtop.field.FieldValue
 
equals(Object) - Method in class org.apache.hadoop.hbase.hbtop.RecordFilter
 
equals(Object) - Method in class org.apache.hadoop.hbase.hbtop.terminal.Attributes
 
equals(Object) - Method in class org.apache.hadoop.hbase.hbtop.terminal.CursorPosition
 
equals(Object) - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.Cell
 
equals(Object) - Method in class org.apache.hadoop.hbase.hbtop.terminal.TerminalSize
 
equals(Object) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
equals(Object) - Method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
 
equals(Object) - Method in class org.apache.hadoop.hbase.HRegionLocation
 
equals(Object) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
Compare the contents of the descriptor with another one passed as a parameter.
equals(Object) - Method in class org.apache.hadoop.hbase.io.FileLink
 
equals(Object) - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheKey
 
equals(Object) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
 
equals(Object) - Method in class org.apache.hadoop.hbase.io.hfile.HFileInfo
 
equals(Object) - Method in class org.apache.hadoop.hbase.io.hfile.LruCachedBlock
 
equals(Object) - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
 
equals(Object) - Method in class org.apache.hadoop.hbase.io.Reference
 
equals(Object) - Method in class org.apache.hadoop.hbase.JitterScheduledThreadPoolExecutorImpl.JitteredRunnableScheduledFuture
 
equals(Object) - Method in class org.apache.hadoop.hbase.KeyValue
Needed doing 'contains' on List.
equals(Object) - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
 
equals(Object) - Method in class org.apache.hadoop.hbase.mapred.TableSplit
 
equals(Object) - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
 
equals(Object) - Method in class org.apache.hadoop.hbase.master.RegionPlan
 
equals(Object) - Method in class org.apache.hadoop.hbase.master.RegionState
Check if two states are the same, except timestamp
equals(Object) - Method in class org.apache.hadoop.hbase.metrics.MetricRegistryInfo
 
equals(Object) - Method in class org.apache.hadoop.hbase.mob.CachedMobFile
 
equals(Object) - Method in class org.apache.hadoop.hbase.mob.MobFileName
 
equals(Object) - Method in class org.apache.hadoop.hbase.net.Address
 
equals(Object) - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
 
equals(Object) - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
 
equals(Object) - Method in class org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot
 
equals(Object) - Method in class org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot.SpaceQuotaStatus
 
equals(Object) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
equals(Object) - Method in class org.apache.hadoop.hbase.regionserver.MemStoreSize
 
equals(Object) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionSourceImpl
 
equals(Object) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableSourceImpl
 
equals(Object) - Method in class org.apache.hadoop.hbase.regionserver.MetricsUserSourceImpl
 
equals(Object) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
 
equals(Object) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
 
equals(Object) - Method in class org.apache.hadoop.hbase.security.User
 
equals(Object) - Method in class org.apache.hadoop.hbase.ServerLoad
Deprecated.
 
equals(Object) - Method in class org.apache.hadoop.hbase.ServerName
 
equals(Object) - Method in class org.apache.hadoop.hbase.Size
 
equals(Object) - Method in class org.apache.hadoop.hbase.SizeCachedByteBufferKeyValue
 
equals(Object) - Method in class org.apache.hadoop.hbase.SizeCachedNoTagsByteBufferKeyValue
 
equals(Object) - Method in class org.apache.hadoop.hbase.SplitLogTask
Deprecated.
 
equals(Object) - Method in class org.apache.hadoop.hbase.TableName
 
equals(Object) - Method in class org.apache.hadoop.hbase.thrift.CallQueue.Call
 
equals(Object) - Method in exception org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler.IOErrorWithCause
 
equals(Object) - Method in class org.apache.hadoop.hbase.tool.coprocessor.CoprocessorMethod
 
equals(Object) - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
 
equals(Object) - Method in class org.apache.hadoop.hbase.util.Bytes
 
equals(Object) - Method in class org.apache.hadoop.hbase.util.HashedBytes
 
equals(Object) - Method in class org.apache.hadoop.hbase.util.HbckRegionInfo.MetaEntry
 
equals(Object) - Method in class org.apache.hadoop.hbase.util.ImmutableByteArray
 
equals(Object) - Method in class org.apache.hadoop.hbase.util.NonceKey
 
equals(Object) - Method in class org.apache.hadoop.hbase.util.ObjectIntPair
 
equals(Object) - Method in class org.apache.hadoop.hbase.util.Pair
 
equals(Object) - Method in class org.apache.hadoop.hbase.util.PairOfSameType
 
equals(Object) - Method in class org.apache.hadoop.hbase.util.SimpleByteRange
 
equals(Object) - Method in class org.apache.hadoop.hbase.util.SimpleMutableByteRange
 
equals(Object) - Method in class org.apache.hadoop.hbase.util.Triple
 
equals(Object) - Method in class org.apache.hadoop.hbase.wal.WALKeyImpl
 
equals(Object) - Method in class org.apache.hadoop.hbase.wal.WALSplitUtil.MutationReplay
 
equals(Object) - Method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp.CreateAndFailSilent
 
equals(Object) - Method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp.DeleteNodeFailSilent
 
equals(Object) - Method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp.SetData
 
equals(ByteBuffer, int, int, byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
Deprecated.
 
equals(ByteBuffer, int, int, ByteBuffer, int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
Deprecated.
 
equals(List<byte[]>, List<byte[]>) - Static method in class org.apache.hadoop.hbase.util.Bytes
 
equals(Cell, Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
equals
equalsIgnoreMvccVersion(Cell, Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
Deprecated.
As of HBase-2.0. Will be removed in HBase-3.0
equalsIgnoreMvccVersion(Cell, Cell) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
special case for Cell.equals
ERASURE_CODING_POLICY - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
If non-null, the HDFS erasure coding policy to set on the data dir of the table
ERASURE_CODING_POLICY - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
 
Err(ServerName) - Constructor for class org.apache.hadoop.hbase.SplitLogTask.Err
Deprecated.
 
ERR - Enum constant in enum org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination.TaskFinisher.Status
task completed with error
ERR - Enum constant in enum org.apache.hadoop.hbase.regionserver.SplitLogWorker.TaskExecutor.Status
Deprecated.
 
error - Variable in class org.apache.hadoop.hbase.master.SplitLogManager.TaskBatch
Deprecated.
 
ERROR - Enum constant in enum org.apache.hadoop.hbase.regionserver.wal.WALActionsListener.RollRequestReason
I/O or other error.
ERROR - Enum constant in enum org.apache.hadoop.hbase.security.SaslStatus
 
ERROR - Enum constant in enum org.apache.hadoop.hbase.tool.coprocessor.CoprocessorViolation.Severity
 
ERROR_AND_RESET - Enum constant in enum org.apache.hadoop.hbase.wal.WALTailingReader.State
This means we meet an error so the upper layer need to reset to read again
ERROR_AND_RESET_COMPRESSION - Enum constant in enum org.apache.hadoop.hbase.wal.WALTailingReader.State
Mostly the same with the above WALTailingReader.State.ERROR_AND_RESET, the difference is that here we also mess up the compression dictionary when reading data, so the upper layer should also clear the compression context when reseting, which means when calling resetTo method, we need to skip to the position instead of just seek to, which will impact performance.
ERROR_ROLL_REQUESTED - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
 
ERROR_ROLL_REQUESTED_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
 
errorHandler - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
 
errorRate - Variable in class org.apache.hadoop.hbase.io.hfile.CompoundBloomFilterBase
Target error rate for configuring the filter and for information
ERRORS - Static variable in class org.apache.hadoop.hbase.util.compaction.MajorCompactor
 
errorText() - Method in class org.apache.hadoop.hbase.client.ClientCoprocessorRpcController
 
errorText() - Method in class org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
 
errorText() - Method in class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
 
errorText() - Method in class org.apache.hadoop.hbase.ipc.ServerRpcController
 
Escape - Enum constant in enum org.apache.hadoop.hbase.hbtop.terminal.KeyPress.Type
 
org.apache.hadoop.hbase.hbtop.terminal.impl.EscapeSequences - Class in org.apache.hadoop.hbase.hbtop.terminal.impl
Utility class for escape sequences.
estimateBase(Class, boolean) - Static method in class org.apache.hadoop.hbase.util.ClassSize
Estimate the static space taken up by the fields of a class.
ESTIMATED_HEAP_TAX - Static variable in class org.apache.hadoop.hbase.util.Bytes
Estimate of size cost to pay beyond payload in jvm for instance of byte [].
estimatedHeapSizeOf(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use RawCell.getTags()
estimatedSerializedSizeOf() - Method in class org.apache.hadoop.hbase.wal.WALEdit
 
estimatedSerializedSizeOf() - Method in interface org.apache.hadoop.hbase.wal.WALKey
 
estimatedSerializedSizeOf() - Method in class org.apache.hadoop.hbase.wal.WALKeyImpl
 
estimatedSerializedSizeOf(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0.
estimatedSerializedSizeOf(Cell) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
Estimate based on keyvalue's serialization format in the RPC layer.
estimatedSerializedSizeOfKey(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0.
estimatedSerializedSizeOfKey(Cell) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
Calculates the serialized key size.
evaluateChallenge(byte[]) - Method in class org.apache.hadoop.hbase.security.AbstractHBaseSaslRpcClient
 
evaluateResponse(byte[]) - Method in class org.apache.hadoop.hbase.security.HBaseSaslRpcServer
 
EVENT_LOOP_CONFIG - Static variable in class org.apache.hadoop.hbase.ipc.NettyRpcClientConfigHelper
 
eventLoopGroup - Variable in class org.apache.hadoop.hbase.wal.AsyncFSWALProvider
Protected visibility for used in tests.
evict() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
 
evict() - Method in class org.apache.hadoop.hbase.mob.MobFileCache
Evicts the lru cached mob files when the count of the cached files is larger than the threshold.
EVICT_BLOCKS_ON_CLOSE - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
EVICT_BLOCKS_ON_CLOSE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
Deprecated.
 
EVICT_BLOCKS_ON_CLOSE_KEY - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
Configuration key to evict all blocks of a given file from the block cache when the file is closed.
evictBlock(BlockCacheKey) - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCache
Evict block from cache.
evictBlock(BlockCacheKey) - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
 
evictBlock(BlockCacheKey) - Method in class org.apache.hadoop.hbase.io.hfile.InclusiveCombinedBlockCache
 
evictBlock(BlockCacheKey) - Method in class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache
 
evictBlock(BlockCacheKey) - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
 
evictBlock(BlockCacheKey) - Method in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
 
evictBlock(BlockCacheKey) - Method in class org.apache.hadoop.hbase.io.hfile.TinyLfuBlockCache
 
evictBlock(LruCachedBlock, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache
Evict the block, and it will be cached by the victim handler if exists && block may be read again later
evictBlock(LruCachedBlock, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
Evict the block, and it will be cached by the victim handler if exists && block may be read again later
evictBlocksByHfileName(String) - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCache
Evicts all blocks for the given HFile.
evictBlocksByHfileName(String) - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
 
evictBlocksByHfileName(String) - Method in class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache
Evicts all blocks for a specific HFile.
evictBlocksByHfileName(String) - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
Evicts all blocks for a specific HFile.
evictBlocksByHfileName(String) - Method in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
This method does nothing so that memcached can handle all evictions.
evictBlocksByHfileName(String) - Method in class org.apache.hadoop.hbase.io.hfile.TinyLfuBlockCache
 
evicted(long, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
 
evictedPerEviction() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
 
evictFile(String) - Method in class org.apache.hadoop.hbase.mob.MobFileCache
Evicts the cached file by the name.
org.apache.hadoop.hbase.quotas.ExceedOperationQuota - Class in org.apache.hadoop.hbase.quotas
 
ExceedOperationQuota(Configuration, int, QuotaLimiter, QuotaLimiter...) - Constructor for class org.apache.hadoop.hbase.quotas.ExceedOperationQuota
 
exceedThrottleQuotaSwitch(boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
Switch the exceed throttle quota.
exceedThrottleQuotaSwitch(boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Switch the exceed throttle quota.
exceedThrottleQuotaSwitch(boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
exception() - Method in interface org.apache.hadoop.hbase.metrics.ExceptionTrackingSource
 
exception() - Method in class org.apache.hadoop.hbase.metrics.ExceptionTrackingSourceImpl
 
exception(Throwable) - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServer
 
exception(Throwable) - Method in class org.apache.hadoop.hbase.thrift.ThriftMetrics
Increment the count for a specific exception type.
EXCEPTION_AUTHFAILED - Static variable in interface org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSource
 
EXCEPTION_AUTHFAILED_DESC - Static variable in interface org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSource
 
EXCEPTION_CONNECTIONLOSS - Static variable in interface org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSource
 
EXCEPTION_CONNECTIONLOSS_DESC - Static variable in interface org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSource
 
EXCEPTION_DATAINCONSISTENCY - Static variable in interface org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSource
 
EXCEPTION_DATAINCONSISTENCY_DESC - Static variable in interface org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSource
 
EXCEPTION_END - Static variable in class org.apache.hadoop.hbase.CompatibilityFactory
 
EXCEPTION_INVALIDACL - Static variable in interface org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSource
 
EXCEPTION_INVALIDACL_DESC - Static variable in interface org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSource
 
EXCEPTION_NOAUTH - Static variable in interface org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSource
 
EXCEPTION_NOAUTH_DESC - Static variable in interface org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSource
 
EXCEPTION_OPERATIONTIMEOUT - Static variable in interface org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSource
 
EXCEPTION_OPERATIONTIMEOUT_DESC - Static variable in interface org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSource
 
EXCEPTION_RUNTIMEINCONSISTENCY - Static variable in interface org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSource
 
EXCEPTION_RUNTIMEINCONSISTENCY_DESC - Static variable in interface org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSource
 
EXCEPTION_SESSIONEXPIRED - Static variable in interface org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSource
 
EXCEPTION_SESSIONEXPIRED_DESC - Static variable in interface org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSource
 
EXCEPTION_START - Static variable in class org.apache.hadoop.hbase.CompatibilityFactory
 
EXCEPTION_SYSTEMERROR - Static variable in interface org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSource
 
EXCEPTION_SYSTEMERROR_DESC - Static variable in interface org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSource
 
exceptionCaught(ChannelHandlerContext, Throwable) - Method in class org.apache.hadoop.hbase.security.NettyHBaseRpcConnectionHeaderHandler
 
exceptionCaught(ChannelHandlerContext, Throwable) - Method in class org.apache.hadoop.hbase.security.NettyHBaseSaslRpcClientHandler
 
exceptionRequestTooBig - Variable in class org.apache.hadoop.hbase.metrics.ExceptionTrackingSourceImpl
 
exceptions - Variable in class org.apache.hadoop.hbase.metrics.ExceptionTrackingSourceImpl
 
EXCEPTIONS_BUSY_NAME - Static variable in interface org.apache.hadoop.hbase.metrics.ExceptionTrackingSource
 
EXCEPTIONS_CALL_DROPPED - Static variable in interface org.apache.hadoop.hbase.metrics.ExceptionTrackingSource
 
EXCEPTIONS_CALL_QUEUE_TOO_BIG - Static variable in interface org.apache.hadoop.hbase.metrics.ExceptionTrackingSource
 
EXCEPTIONS_CALL_QUEUE_TOO_BIG_DESC - Static variable in interface org.apache.hadoop.hbase.metrics.ExceptionTrackingSource
 
EXCEPTIONS_CALL_TIMED_OUT - Static variable in interface org.apache.hadoop.hbase.metrics.ExceptionTrackingSource
 
EXCEPTIONS_DESC - Static variable in interface org.apache.hadoop.hbase.metrics.ExceptionTrackingSource
 
EXCEPTIONS_MOVED_NAME - Static variable in interface org.apache.hadoop.hbase.metrics.ExceptionTrackingSource
 
EXCEPTIONS_MULTI_TOO_LARGE_DESC - Static variable in interface org.apache.hadoop.hbase.metrics.ExceptionTrackingSource
 
EXCEPTIONS_MULTI_TOO_LARGE_NAME - Static variable in interface org.apache.hadoop.hbase.metrics.ExceptionTrackingSource
 
EXCEPTIONS_NAME - Static variable in interface org.apache.hadoop.hbase.metrics.ExceptionTrackingSource
 
EXCEPTIONS_NSRE_NAME - Static variable in interface org.apache.hadoop.hbase.metrics.ExceptionTrackingSource
 
EXCEPTIONS_OOO_NAME - Static variable in interface org.apache.hadoop.hbase.metrics.ExceptionTrackingSource
 
EXCEPTIONS_QUOTA_EXCEEDED - Static variable in interface org.apache.hadoop.hbase.metrics.ExceptionTrackingSource
 
EXCEPTIONS_REQUEST_TOO_BIG - Static variable in interface org.apache.hadoop.hbase.metrics.ExceptionTrackingSource
 
EXCEPTIONS_RPC_THROTTLING - Static variable in interface org.apache.hadoop.hbase.metrics.ExceptionTrackingSource
 
EXCEPTIONS_SANITY_NAME - Static variable in interface org.apache.hadoop.hbase.metrics.ExceptionTrackingSource
 
EXCEPTIONS_SCANNER_RESET_NAME - Static variable in interface org.apache.hadoop.hbase.metrics.ExceptionTrackingSource
 
EXCEPTIONS_TYPE_DESC - Static variable in interface org.apache.hadoop.hbase.metrics.ExceptionTrackingSource
 
EXCEPTIONS_UNKNOWN_NAME - Static variable in interface org.apache.hadoop.hbase.metrics.ExceptionTrackingSource
 
exceptionsBusy - Variable in class org.apache.hadoop.hbase.metrics.ExceptionTrackingSourceImpl
 
exceptionsCallDropped - Variable in class org.apache.hadoop.hbase.metrics.ExceptionTrackingSourceImpl
 
exceptionsCallQueueTooBig - Variable in class org.apache.hadoop.hbase.metrics.ExceptionTrackingSourceImpl
 
exceptionsCallTimedOut - Variable in class org.apache.hadoop.hbase.metrics.ExceptionTrackingSourceImpl
 
exceptionsMoved - Variable in class org.apache.hadoop.hbase.metrics.ExceptionTrackingSourceImpl
 
exceptionsMultiTooLarge - Variable in class org.apache.hadoop.hbase.metrics.ExceptionTrackingSourceImpl
 
exceptionsNSRE - Variable in class org.apache.hadoop.hbase.metrics.ExceptionTrackingSourceImpl
 
exceptionsOOO - Variable in class org.apache.hadoop.hbase.metrics.ExceptionTrackingSourceImpl
 
exceptionsQuotaExceeded - Variable in class org.apache.hadoop.hbase.metrics.ExceptionTrackingSourceImpl
 
exceptionsRpcThrottling - Variable in class org.apache.hadoop.hbase.metrics.ExceptionTrackingSourceImpl
 
exceptionsSanity - Variable in class org.apache.hadoop.hbase.metrics.ExceptionTrackingSourceImpl
 
exceptionsScannerReset - Variable in class org.apache.hadoop.hbase.metrics.ExceptionTrackingSourceImpl
 
exceptionsUnknown - Variable in class org.apache.hadoop.hbase.metrics.ExceptionTrackingSourceImpl
 
org.apache.hadoop.hbase.metrics.ExceptionTrackingSource - Interface in org.apache.hadoop.hbase.metrics
Common interface for metrics source implementations which need to track individual exception types thrown or received.
org.apache.hadoop.hbase.metrics.ExceptionTrackingSourceImpl - Class in org.apache.hadoop.hbase.metrics
Common base implementation for metrics sources which need to track exceptions thrown or received.
ExceptionTrackingSourceImpl(String, String, String, String) - Constructor for class org.apache.hadoop.hbase.metrics.ExceptionTrackingSourceImpl
 
org.apache.hadoop.hbase.util.ExceptionUtil - Class in org.apache.hadoop.hbase.util
This class handles the different interruption classes.
EXCLUDE - Enum constant in enum org.apache.hadoop.hbase.filter.FilterWrapper.FilterRowRetCode
 
EXCLUDE_FROM_MINOR_COMPACTION_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.HStoreFile
Minor compaction flag in FileInfo
excludeCiphers(String) - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
 
org.apache.hadoop.hbase.io.asyncfs.monitor.ExcludeDatanodeManager - Class in org.apache.hadoop.hbase.io.asyncfs.monitor
The class to manage the excluded datanodes of the WALs on the regionserver.
ExcludeDatanodeManager(Configuration) - Constructor for class org.apache.hadoop.hbase.io.asyncfs.monitor.ExcludeDatanodeManager
 
excludeFile(String) - Method in class org.apache.hadoop.hbase.util.RegionMover.RegionMoverBuilder
Path of file containing hostnames to be excluded during region movement.
excludeFromMinorCompaction() - Method in class org.apache.hadoop.hbase.regionserver.HStoreFile
 
excludeFromMinorCompaction() - Method in interface org.apache.hadoop.hbase.regionserver.StoreFile
Returns True if this file should not be part of a minor compaction.
org.apache.hadoop.hbase.io.hfile.ExclusiveMemHFileBlock - Class in org.apache.hadoop.hbase.io.hfile
The ByteBuffAllocator won't allocate pooled heap ByteBuff now; at the same time, if allocate an off-heap ByteBuff from allocator, then it must be a pooled one.
exec(String, CancelableProgressable) - Method in interface org.apache.hadoop.hbase.regionserver.SplitLogWorker.TaskExecutor
Deprecated.
 
exec(ExecutorService, String[]) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
Deprecated.
 
execMasterService(RpcController, ClientProtos.CoprocessorServiceRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
execMasterService(RpcController, ClientProtos.CoprocessorServiceRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
 
execOperation(CoprocessorHost.ObserverOperation<O>) - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
 
execOperationWithResult(CoprocessorHost.ObserverOperationWithResult<O, R>) - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
Do not call with an observerOperation that is null! Have the caller check.
execProcedure(String, String, Map<String, String>) - Method in interface org.apache.hadoop.hbase.client.Admin
Execute a distributed procedure on a cluster.
execProcedure(String, String, Map<String, String>) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Execute a distributed procedure on a cluster.
execProcedure(String, String, Map<String, String>) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
execProcedure(RpcController, MasterProtos.ExecProcedureRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
execProcedure(RpcController, MasterProtos.ExecProcedureRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
Triggers an asynchronous attempt to run a distributed procedure.
execProcedureWithRet(String, String, Map<String, String>) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
Since 2.0.0. Will be removed in 3.0.0. Use Admin.execProcedureWithReturn(String, String, Map) } instead.
execProcedureWithRet(RpcController, MasterProtos.ExecProcedureRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
execProcedureWithRet(RpcController, MasterProtos.ExecProcedureRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
Triggers a synchronous attempt to run a distributed procedure and sets return data in response.
execProcedureWithReturn(String, String, Map<String, String>) - Method in interface org.apache.hadoop.hbase.client.Admin
Execute a distributed procedure on a cluster.
execProcedureWithReturn(String, String, Map<String, String>) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Execute a distributed procedure on a cluster.
execProcedureWithReturn(String, String, Map<String, String>) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
execRegionServerService(RpcController, ClientProtos.CoprocessorServiceRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
 
execService(RpcController, ClientProtos.CoprocessorServiceCall) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Executes a single protocol buffer coprocessor endpoint Service method using the registered protocol handlers.
execService(RpcController, ClientProtos.CoprocessorServiceRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
 
execShutdown(CoprocessorHost.ObserverOperation<O>) - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
Coprocessor classes can be configured in any order, based on that priority is set and chained in a sorted order.
execute() - Method in class org.apache.hadoop.hbase.chaos.ChaosAgent.LocalShell
 
execute() - Method in interface org.apache.hadoop.hbase.client.AsyncTable.CoprocessorServiceBuilder
Execute the coprocessorService request.
execute(String[], Configuration) - Static method in class org.apache.hadoop.hbase.chaos.ChaosService
 
execute(Record) - Method in class org.apache.hadoop.hbase.hbtop.RecordFilter
 
execute(Cluster, HttpUriRequest, Header[], String) - Method in class org.apache.hadoop.hbase.rest.client.Client
Execute a transaction method.
executeFromState(MasterProcedureEnv, MasterProcedureProtos.ModifyStoreFileTrackerState) - Method in class org.apache.hadoop.hbase.regionserver.storefiletracker.ModifyStoreFileTrackerProcedure
 
executePathOnly(Cluster, HttpUriRequest, Header[], String) - Method in class org.apache.hadoop.hbase.rest.client.Client
Execute a transaction method given only the path.
executeProcedures(RpcController, AdminProtos.ExecuteProceduresRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
 
executeRegionPlansWithThrottling(List<RegionPlan>) - Method in class org.apache.hadoop.hbase.master.HMaster
Execute region plans with throttling
executeRegionPlansWithThrottling(List<RegionPlan>) - Method in interface org.apache.hadoop.hbase.master.MasterServices
Execute region plans with throttling
executeRpcCall(ThreadPoolExecutor, AtomicInteger, CallRunner) - Method in class org.apache.hadoop.hbase.ipc.FifoRpcScheduler
 
executeURI(HttpUriRequest, Header[], String) - Method in class org.apache.hadoop.hbase.rest.client.Client
Execute a transaction method given a complete URI.
executor - Variable in class org.apache.hadoop.hbase.ipc.FifoRpcScheduler
 
executor - Variable in class org.apache.hadoop.hbase.util.compaction.MajorCompactor
 
executor - Variable in class org.apache.hadoop.hbase.util.HBaseFsck
Deprecated.
 
executorService - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
existingSource - Variable in class org.apache.hadoop.hbase.metrics.MetricRegistryInfo
 
existingWriters - Variable in class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter
 
exists(String) - Method in class org.apache.hadoop.hbase.zookeeper.ReadOnlyZKClient
 
exists(String, boolean) - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
exists is an idempotent operation.
exists(String, Watcher) - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
exists is an idempotent operation.
exists(List<Get>) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
Test for the existence of columns in the table, as specified by the Gets.
exists(List<Get>) - Method in class org.apache.hadoop.hbase.client.HTable
 
exists(List<Get>) - Method in interface org.apache.hadoop.hbase.client.Table
Test for the existence of columns in the table, as specified by the Gets.
exists(Configuration, FileSystem, RegionInfo) - Static method in class org.apache.hadoop.hbase.backup.HFileArchiver
Returns True if the Region exits in the filesystem.
exists(FileSystem) - Method in class org.apache.hadoop.hbase.io.FileLink
Returns true if the file pointed by the link exists
exists(Get) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
Test for the existence of columns in the table, as specified by the Get.
exists(Get) - Method in class org.apache.hadoop.hbase.client.HTable
 
exists(Get) - Method in interface org.apache.hadoop.hbase.client.Table
Test for the existence of columns in the table, as specified by the Get.
exists(TableName) - Method in interface org.apache.hadoop.hbase.TableDescriptors
Test whether a given table exists, i.e, has a table descriptor.
existsAll(List<Get>) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
A simple version for batch exists.
existsAll(List<Get>) - Method in interface org.apache.hadoop.hbase.client.Table
Deprecated.
since 2.0 version and will be removed in 3.0 version. use Table.exists(List)
org.apache.hadoop.hbase.rest.ExistsResource - Class in org.apache.hadoop.hbase.rest
 
ExistsResource(TableResource) - Constructor for class org.apache.hadoop.hbase.rest.ExistsResource
Constructor
EXIT_FAILURE - Static variable in class org.apache.hadoop.hbase.util.AbstractHBaseTool
 
EXIT_SUCCESS - Static variable in class org.apache.hadoop.hbase.util.AbstractHBaseTool
 
exitIfOOME(Throwable) - Static method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
 
expectAtLeastMajorVersion(int) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
 
expectMajorVersion(int) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
 
expectMinorVersion(int) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
 
expectPBMagicPrefix(byte[]) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
Expect the ProtobufMagic.PB_MAGIC or throw an exception.
expectSpecific() - Method in enum org.apache.hadoop.hbase.io.hfile.BlockType.BlockCategory
Throws an exception if the block category passed is the special category meaning "all categories".
expired(ServerName) - Method in class org.apache.hadoop.hbase.master.MasterRegionServerList
 
expired(ServerName) - Method in interface org.apache.hadoop.hbase.master.RegionServerList
Called when a region server is dead.
EXPIRED_TABLE_LOCK - Enum constant in enum org.apache.hadoop.hbase.util.HbckErrorReporter.ERROR_CODE
Deprecated.
 
org.apache.hadoop.hbase.mob.ExpiredMobFileCleaner - Class in org.apache.hadoop.hbase.mob
The cleaner to delete the expired MOB files.
ExpiredMobFileCleaner() - Constructor for class org.apache.hadoop.hbase.mob.ExpiredMobFileCleaner
 
expireServer(ServerName) - Method in class org.apache.hadoop.hbase.master.ServerManager
Expire the passed server.
org.apache.hadoop.hbase.regionserver.querymatcher.ExplicitColumnTracker - Class in org.apache.hadoop.hbase.regionserver.querymatcher
This class is used for the tracking and enforcement of columns and numbers of versions during the course of a Get or Scan operation, when explicit column qualifiers have been asked for in the query.
ExplicitColumnTracker(NavigableSet<byte[]>, int, int, long) - Constructor for class org.apache.hadoop.hbase.regionserver.querymatcher.ExplicitColumnTracker
Default constructor.
ExponentialBackoffPolicy() - Constructor for class org.apache.hadoop.hbase.util.RetryCounter.ExponentialBackoffPolicy
 
ExponentialBackoffPolicyWithLimit() - Constructor for class org.apache.hadoop.hbase.util.RetryCounter.ExponentialBackoffPolicyWithLimit
 
org.apache.hadoop.hbase.client.backoff.ExponentialClientBackoffPolicy - Class in org.apache.hadoop.hbase.client.backoff
Simple exponential backoff policy on for the client that uses a percent^4 times the max backoff to generate the backoff time.
ExponentialClientBackoffPolicy(Configuration) - Constructor for class org.apache.hadoop.hbase.client.backoff.ExponentialClientBackoffPolicy
 
org.apache.hadoop.hbase.util.ExponentialMovingAverage<T> - Class in org.apache.hadoop.hbase.util
EMA is similar to WeightedMovingAverage in weighted, but the weighting factor decrease exponentially.
ExponentialMovingAverage(String) - Constructor for class org.apache.hadoop.hbase.util.ExponentialMovingAverage
 
ExponentialMovingAverage(String, double) - Constructor for class org.apache.hadoop.hbase.util.ExponentialMovingAverage
 
ExponentialMovingAverage(String, int) - Constructor for class org.apache.hadoop.hbase.util.ExponentialMovingAverage
 
ExponentialMovingAverage(String, int, double) - Constructor for class org.apache.hadoop.hbase.util.ExponentialMovingAverage
 
org.apache.hadoop.hbase.mapreduce.Export - Class in org.apache.hadoop.hbase.mapreduce
Export an HBase table.
Export() - Constructor for class org.apache.hadoop.hbase.mapreduce.Export
 
EXPORT_BATCHING - Static variable in class org.apache.hadoop.hbase.mapreduce.ExportUtils
 
EXPORT_CACHING - Static variable in class org.apache.hadoop.hbase.mapreduce.ExportUtils
 
EXPORT_VISIBILITY_LABELS - Static variable in class org.apache.hadoop.hbase.mapreduce.ExportUtils
 
org.apache.hadoop.hbase.client.example.ExportEndpointExample - Class in org.apache.hadoop.hbase.client.example
A simple example on how to use Export.
org.apache.hadoop.hbase.snapshot.ExportSnapshot - Class in org.apache.hadoop.hbase.snapshot
Export the specified snapshot to a given FileSystem.
ExportSnapshot() - Constructor for class org.apache.hadoop.hbase.snapshot.ExportSnapshot
 
org.apache.hadoop.hbase.snapshot.ExportSnapshot.Counter - Enum in org.apache.hadoop.hbase.snapshot
 
org.apache.hadoop.hbase.snapshot.ExportSnapshotException - Exception in org.apache.hadoop.hbase.snapshot
Thrown when a snapshot could not be exported due to an error during the operation.
ExportSnapshotException(String) - Constructor for exception org.apache.hadoop.hbase.snapshot.ExportSnapshotException
 
ExportSnapshotException(String, Exception) - Constructor for exception org.apache.hadoop.hbase.snapshot.ExportSnapshotException
 
org.apache.hadoop.hbase.mapreduce.ExportUtils - Class in org.apache.hadoop.hbase.mapreduce
Some helper methods are used by Export and org.apache.hadoop.hbase.coprocessor.Export (in hbase-endpooint).
EXTENDED_CELL_SERIALIZATION_ENABLED_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
ExtendedCell and ExtendedCellSerialization are InterfaceAudience.Private.
org.apache.hadoop.hbase.ExtendedCell - Interface in org.apache.hadoop.hbase
Extension to Cell with server side required functions.
org.apache.hadoop.hbase.ExtendedCellBuilder - Interface in org.apache.hadoop.hbase
For internal purpose.
org.apache.hadoop.hbase.ExtendedCellBuilderFactory - Class in org.apache.hadoop.hbase
 
org.apache.hadoop.hbase.ExtendedCellBuilderImpl - Class in org.apache.hadoop.hbase
 
ExtendedCellBuilderImpl() - Constructor for class org.apache.hadoop.hbase.ExtendedCellBuilderImpl
 
ExtendedCellDeserializer() - Constructor for class org.apache.hadoop.hbase.mapreduce.ExtendedCellSerialization.ExtendedCellDeserializer
 
org.apache.hadoop.hbase.mapreduce.ExtendedCellSerialization - Class in org.apache.hadoop.hbase.mapreduce
Similar to CellSerialization, but includes the sequenceId from an ExtendedCell.
ExtendedCellSerialization() - Constructor for class org.apache.hadoop.hbase.mapreduce.ExtendedCellSerialization
 
org.apache.hadoop.hbase.mapreduce.ExtendedCellSerialization.ExtendedCellDeserializer - Class in org.apache.hadoop.hbase.mapreduce
 
org.apache.hadoop.hbase.mapreduce.ExtendedCellSerialization.ExtendedCellSerializer - Class in org.apache.hadoop.hbase.mapreduce
 
ExtendedCellSerializer() - Constructor for class org.apache.hadoop.hbase.mapreduce.ExtendedCellSerialization.ExtendedCellSerializer
 
extendedForName(String) - Static method in class org.apache.hadoop.hbase.util.Classes
Equivalent of Class.forName(String) which also returns classes for primitives like boolean, etc.
extendLimit(ByteBuffer, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
Deprecated.
 
extractArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.CompareFilter
Returns an array of heterogeneous objects
extractFileNumFromWAL(WAL) - Static method in class org.apache.hadoop.hbase.wal.AbstractFSWALProvider
It returns the file create timestamp from the file name.
extractFilterSimpleExpression(byte[], int) - Method in class org.apache.hadoop.hbase.filter.ParseFilter
Extracts a simple filter expression from the filter string given by the user
extractHiddenEof(Exception) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractProtobufWALReader
 
extractKeyValues(Result) - Method in class org.apache.hadoop.hbase.mapred.GroupingTableMap
Extract columns values from the current record.
extractKeyValues(Result) - Method in class org.apache.hadoop.hbase.mapreduce.GroupingTableMapper
Extract columns values from the current record.
extractQuotaSnapshot(Result, Map<TableName, SpaceQuotaSnapshot>) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
Extracts the SpaceViolationPolicy and TableName from the provided Result and adds them to the given Map.
extractScanFromConf(Configuration) - Static method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl
 
extractSnapshotNameFromSizeCell(Cell) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
extractSnapshotSize(byte[], int, int) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
 
extraHeapSize() - Method in class org.apache.hadoop.hbase.client.Append
 
extraHeapSize() - Method in class org.apache.hadoop.hbase.client.Increment
 
extraHeapSize() - Method in class org.apache.hadoop.hbase.client.Mutation
Subclasses should override this method to add the heap size of their own fields.

F

F1 - Enum constant in enum org.apache.hadoop.hbase.hbtop.terminal.KeyPress.Type
 
F10 - Enum constant in enum org.apache.hadoop.hbase.hbtop.terminal.KeyPress.Type
 
F11 - Enum constant in enum org.apache.hadoop.hbase.hbtop.terminal.KeyPress.Type
 
F12 - Enum constant in enum org.apache.hadoop.hbase.hbtop.terminal.KeyPress.Type
 
F2 - Enum constant in enum org.apache.hadoop.hbase.hbtop.terminal.KeyPress.Type
 
F3 - Enum constant in enum org.apache.hadoop.hbase.hbtop.terminal.KeyPress.Type
 
F4 - Enum constant in enum org.apache.hadoop.hbase.hbtop.terminal.KeyPress.Type
 
F5 - Enum constant in enum org.apache.hadoop.hbase.hbtop.terminal.KeyPress.Type
 
F6 - Enum constant in enum org.apache.hadoop.hbase.hbtop.terminal.KeyPress.Type
 
F7 - Enum constant in enum org.apache.hadoop.hbase.hbtop.terminal.KeyPress.Type
 
F8 - Enum constant in enum org.apache.hadoop.hbase.hbtop.terminal.KeyPress.Type
 
F9 - Enum constant in enum org.apache.hadoop.hbase.hbtop.terminal.KeyPress.Type
 
factory - Variable in class org.apache.hadoop.hb