Index
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 class org.apache.hadoop.hbase.master.RegionState.State
- abort() - Method in class org.apache.hadoop.hdfs.DummyDFSOutputStream
- 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.HBaseHbck
- abort(String, Throwable) - Method in class org.apache.hadoop.hbase.client.SharedConnection
- abort(String, Throwable) - Method in class org.apache.hadoop.hbase.master.HMaster
- abort(String, Throwable) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster.MiniHBaseClusterRegionServer
-
Deprecated.
- abort(String, Throwable) - Method in class org.apache.hadoop.hbase.MockRegionServerServices
- 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.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.AbstractWALProvider
- 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 - Variable in class org.apache.hadoop.hbase.util.MultiThreadedReader
- ABORTED - Enum constant in enum class org.apache.hadoop.hbase.ServerTask.State
- abortMaster(int) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.Cause a master to exit without shutting down entire cluster.
- 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.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.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.
- abortRegionServer(int) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.Cause a region server to exit doing basic clean up only on its way out.
- abortRequested - Variable in class org.apache.hadoop.hbase.HBaseServerBase
- 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 againstFileSystem
; i.e. - AbstractFSWAL(FileSystem, Abortable, Path, String, String, Configuration, List<WALActionsListener>, boolean, String, String, FileSystem, Path) - 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.AbstractWALProvider - Class in org.apache.hadoop.hbase.wal
-
Base class for a WAL Provider.
- AbstractWALProvider() - Constructor for class org.apache.hadoop.hbase.wal.AbstractWALProvider
- 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.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(T) - Method in interface org.apache.hadoop.hbase.util.IOExceptionConsumer
- 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 class org.apache.hadoop.hbase.Coprocessor.State
- ACTIVE - Enum constant in enum class org.apache.hadoop.hbase.regionserver.wal.WALEventTrackerListener.WalState
- ACTIVE - Enum constant in enum class org.apache.hadoop.hbase.replication.SyncReplicationState
- 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 class 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[]) - 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(int, E) - Method in class org.apache.hadoop.hbase.util.SortedList
- 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<ExtendedCell>, MemStoreSizing) - Method in class org.apache.hadoop.hbase.regionserver.AbstractMemStore
- add(Iterable<ExtendedCell>, MemStoreSizing) - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
Adds the specified value to the memstore
- add(Iterable<ExtendedCell>, 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<byte[], List<Cell>>) - Method in class org.apache.hadoop.hbase.wal.WALEdit
-
This is just for keeping compatibility for CPs, in HBase you should call the below
WALEdit.addMap(Map)
directly to avoid casting. - 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.util.BloomFilterChunk
- add(Cell) - Method in class org.apache.hadoop.hbase.wal.WALEdit
- add(Cell, byte[]) - Method in class org.apache.hadoop.hbase.wal.WALEdit
- add(Mutation) - Method in class org.apache.hadoop.hbase.client.RowMutations
-
Add a mutation
- add(ExtendedCell) - 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(ExtendedCell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.NewVersionBehaviorTracker
- add(ExtendedCell) - 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(ExtendedCell, boolean, MemStoreSizing, boolean) - Method in class org.apache.hadoop.hbase.regionserver.MutableSegment
-
Adds the given cell into the segment
- add(ExtendedCell, MemStoreSizing) - Method in class org.apache.hadoop.hbase.regionserver.AbstractMemStore
- add(ExtendedCell, MemStoreSizing) - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
Adds a value to the memstore
- add(ExtendedCell, MemStoreSizing) - Method in interface org.apache.hadoop.hbase.regionserver.MemStore
-
Write an update
- 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(WALKeyImpl, WALEdit, ServerCall<?>) - Method in class org.apache.hadoop.hbase.regionserver.regionreplication.RegionReplicationSink
-
Add this edit to replication queue.
- 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.regionserver.CellSet
- 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 CallRunner>) - Method in class org.apache.hadoop.hbase.ipc.AdaptiveLifoCoDelCallQueue
- addAll(Collection<? extends T>) - Method in class org.apache.hadoop.hbase.regionserver.CellSet
- 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
-
Deprecated.Since 3.0.0, will be removed in 4.0.0. The rsgroup information will be stored in the configuration of a table so this will be removed.
- 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
- addClickjackingPreventionFilter(ServletContextHandler, Configuration, String) - Static method in class org.apache.hadoop.hbase.http.HttpServerUtil
- 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, 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.master.MasterRpcServices
- 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.
- 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.
- addCommandDescriptor(Class<? extends PerformanceEvaluation.TestBase>, String, String) - Static method in class org.apache.hadoop.hbase.PerformanceEvaluation
- 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
- addCostFuncInfo(String, double, float) - Method in class org.apache.hadoop.hbase.client.BalancerRejection.Builder
- addDaughtersToPut(Put, RegionInfo, RegionInfo) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Adds split daughters to the Put
- 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
- 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.
- 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
- addExtendedCell(WALEdit, List<ExtendedCell>) - Static method in class org.apache.hadoop.hbase.wal.WALEditInternalHelper
- addExtendedCell(WALEdit, ExtendedCell) - Static method in class org.apache.hadoop.hbase.wal.WALEditInternalHelper
- 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.
- 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.
- addHFileRefs(String, List<Pair<Path, Path>>) - Method in class org.apache.hadoop.hbase.replication.TableReplicationQueueStorage
- 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
- 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 callCompletableFuture.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
- addMap(WALEdit, Map<byte[], List<ExtendedCell>>) - Static method in class org.apache.hadoop.hbase.wal.WALEditInternalHelper
- 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.ScanPerformanceEvaluation
- 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.LoadTestTool
- 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
- addOrUpdateNamespace(NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.master.TableNamespaceManager
- addPeer(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeers
-
Method called after a peer has been connected.
- addPeer(String, ReplicationPeerConfig, boolean, SyncReplicationState) - Method in class org.apache.hadoop.hbase.replication.FSReplicationPeerStorage
- addPeer(String, ReplicationPeerConfig, boolean, SyncReplicationState) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeerStorage
-
Add a replication peer.
- addPeer(String, ReplicationPeerConfig, boolean, SyncReplicationState) - Method in class org.apache.hadoop.hbase.replication.ZKReplicationPeerStorage
- 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
- addReaderThreads(int) - Method in class org.apache.hadoop.hbase.util.MultiThreadedReader
- addReaderThreads(int) - Method in class org.apache.hadoop.hbase.util.MultiThreadedReaderWithACL
- 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.MockRegionServerServices
- 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
- addRegionStateToPut(Put, int, RegionState.State) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Set the column value corresponding to this
replicaId
'sRegionState
to the providedstate
. - 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.
- addRegionsToMeta(Connection, List<RegionInfo>, int, long) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Adds a hbase:meta row for each of the specified new regions.
- 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.replication.ReplicationBarrierFamilyFormat
- addReplicationParent(Put, List<RegionInfo>) - Static method in class org.apache.hadoop.hbase.replication.ReplicationBarrierFamilyFormat
- 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.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.
- 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
- addRow(byte[]) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility.SeenRowTracker
-
Deprecated.
- addRSGroup(String) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Creates a new RegionServer group with the given name
- addRSGroup(String) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Creates a new RegionServer group with the given name
- addRSGroup(String) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminClient
-
Deprecated.Creates a new RegionServer group with the given name.
- addRSGroup(RSGroupInfo) - Method in interface org.apache.hadoop.hbase.rsgroup.RSGroupInfoManager
-
Add given RSGroupInfo to existing list of group infos.
- addRSGroup(RpcController, RSGroupAdminProtos.AddRSGroupRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- 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.
- addScanResultCells(List<Cell>) - Method in class org.apache.hadoop.hbase.quotas.DefaultOperationQuota
- addScanResultCells(List<Cell>) - Method in interface org.apache.hadoop.hbase.quotas.OperationQuota
-
Add a scan result in the form of cells.
- addSecurityHeadersFilter(ServletContextHandler, Configuration, boolean, String) - Static method in class org.apache.hadoop.hbase.http.HttpServerUtil
- 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)
orInfoServer.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>, 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
-
Deprecated.Since 3.0.0, will be removed in 4.0.0. The rsgroup information will be stored in the configuration of a table so this will be removed.
- 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.
- addUpdaterThreads(int) - Method in class org.apache.hadoop.hbase.util.MultiThreadedUpdater
- addUpdaterThreads(int) - Method in class org.apache.hadoop.hbase.util.MultiThreadedUpdaterWithACL
- 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(ExtendedCell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.NewVersionBehaviorTracker.DeleteVersionsNode
- 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.AbstractWALProvider
- 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
- afterDecodingKeyValue(DataInputStream, ByteBuffer, HFileBlockDefaultDecodingContext) - Method in class org.apache.hadoop.hbase.io.encoding.PrefixKeyDeltaEncoder
- afterEncodingKeyValue(ExtendedCell, DataOutputStream, HFileBlockDefaultEncodingContext) - Method in class org.apache.hadoop.hbase.io.encoding.PrefixKeyDeltaEncoder
-
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 class org.apache.hadoop.hbase.ClientMetaTableAccessor.QueryType
- ALL_CATEGORIES - Enum constant in enum class 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 class org.apache.hadoop.hbase.client.LogQueryFilter.FilterByOperator
-
Deprecated.
- AND - Enum constant in enum class 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.ipc.AnnotationReadingPriorityFunction
- org.apache.hadoop.hbase.ipc.AnnotationReadingPriorityFunction<T extends org.apache.hadoop.hbase.HBaseRpcServicesBase<?>> - Class in org.apache.hadoop.hbase.ipc
-
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(T) - Constructor for class org.apache.hadoop.hbase.ipc.AnnotationReadingPriorityFunction
-
Constructs the priority function given the RPC server implementation and the annotations on the methods.
- ANY - Enum constant in enum class org.apache.hadoop.hbase.backup.BackupInfo.BackupState
- ANY - Enum constant in enum class 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(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 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(ExtendedCell) - Method in class org.apache.hadoop.hbase.io.hfile.CompoundBloomFilterWriter
- append(ExtendedCell) - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterImpl
-
Add key/value to file.
- append(ExtendedCell) - Method in interface org.apache.hadoop.hbase.regionserver.CellSink
-
Append the given cell
- append(ExtendedCell) - Method in class org.apache.hadoop.hbase.regionserver.DateTieredMultiFileWriter
- append(ExtendedCell) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileWriter
- append(ExtendedCell) - Method in class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter.BoundaryMultiWriter
- append(ExtendedCell) - Method in class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter.SizeMultiWriter
- append(TAppend) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
- 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.CombinedAsyncWriter
- append(WAL.Entry) - Method in class org.apache.hadoop.hbase.regionserver.wal.CombinedWriter
- 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 class org.apache.hadoop.hbase.coprocessor.RegionObserver.MutationType
- APPEND - Enum constant in enum class 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
- appendAll(List<ExtendedCell>) - Method in interface org.apache.hadoop.hbase.regionserver.CellSink
-
Append the given (possibly partial) list of cells of a row
- appendAll(List<ExtendedCell>) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileWriter
- 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(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 anAppend
. - appendKeyTo(ExtendedCell, byte[], int) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
- appendKeyTo(ExtendedCell, 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)
- 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(ExtendedCell, 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(ExtendedCell, 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
- appendToStatus(StringBuilder, String, long) - Static method in class org.apache.hadoop.hbase.util.MultiThreadedAction
- appendToStatus(StringBuilder, String, String) - Static method in class org.apache.hadoop.hbase.util.MultiThreadedAction
- appendTrackedTimestampsToMetadata() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileWriter
-
Add TimestampRange and earliest put timestamp to Metadata
- apply(byte) - Method in enum class org.apache.hadoop.hbase.util.Order
-
Apply order to the byte
val
. - apply(byte[]) - Method in enum class org.apache.hadoop.hbase.util.Order
-
Apply order to the byte array
val
. - apply(byte[], int, int) - Method in enum class 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
- apply(T1, T2) - Method in interface org.apache.hadoop.hbase.client.VersionInfoUtil.ServiceCallFunction
- applyColumnFamilyOptions(TableName, byte[][]) - Method in class org.apache.hadoop.hbase.util.LoadTestTool
-
Apply column family options such as Bloom filters, compression, and data block encoding.
- applyFilterAndGet(List<Record>, List<RecordFilter>) - Static method in class org.apache.hadoop.hbase.hbtop.mode.ModeStrategyUtils
-
Filter records as per the supplied filters,
- applyURIQueriesToConf(URI, Configuration) - Static method in class org.apache.hadoop.hbase.util.Strings
-
Apply the key value pairs in the query string of the given URI to the given Configuration.
- 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.
- 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
-
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 class 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 class 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 class 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 class 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 class org.apache.hadoop.hbase.hbtop.terminal.KeyPress.Type
- ASCENDING - Enum constant in enum class org.apache.hadoop.hbase.util.Order
- ASCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedBlob
-
Deprecated.since 3.0.0 and will be removed in 4.0.0
- ASCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedBlobVar
-
Deprecated.since 3.0.0 and will be removed in 4.0.0
- ASCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedFloat32
-
Deprecated.since 3.0.0 and will be removed in 4.0.0
- ASCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedFloat64
-
Deprecated.since 3.0.0 and will be removed in 4.0.0
- ASCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedInt16
-
Deprecated.since 3.0.0 and will be removed in 4.0.0
- ASCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedInt32
-
Deprecated.since 3.0.0 and will be removed in 4.0.0
- ASCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedInt64
-
Deprecated.since 3.0.0 and will be removed in 4.0.0
- ASCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedInt8
-
Deprecated.since 3.0.0 and will be removed in 4.0.0
- ASCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedNumeric
-
Deprecated.since 3.0.0 and will be removed in 4.0.0
- ASCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedString
-
Deprecated.since 3.0.0 and will be removed in 4.0.0
- ASCENDING - Static variable in class org.apache.hadoop.hbase.types.RawBytes
-
Deprecated.since 3.0.0 and will be removed in 4.0.0
- ASCENDING - Static variable in class org.apache.hadoop.hbase.types.RawString
-
Deprecated.since 3.0.0 and will be removed in 4.0.0
- 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.
- assertKey(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.PerformanceEvaluationCommons
- assertKey(byte[], byte[], int, int) - Static method in class org.apache.hadoop.hbase.PerformanceEvaluationCommons
- assertKey(byte[], ByteBuffer) - Static method in class org.apache.hadoop.hbase.PerformanceEvaluationCommons
- assertKey(byte[], Cell) - Static method in class org.apache.hadoop.hbase.PerformanceEvaluationCommons
- assertKVListsEqual(String, List<? extends Cell>, List<? extends Cell>) - Static method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- assertRegionOnlyOnServer(RegionInfo, ServerName, long) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Check to make sure the region is open on the specified region server, but not on any other one.
- assertRegionOnServer(RegionInfo, ServerName, long) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Due to async racing issue, a region may not be in the online region list of a region server yet, after the assignment znode is deleted and the new assignment is recorded in master.
- 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
- assertValueSize(int, int) - Static method in class org.apache.hadoop.hbase.PerformanceEvaluationCommons
- 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_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(RegionInfo) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Uses directly the assignment manager to assign the region.
- 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 interface org.apache.hadoop.hbase.client.Hbck
- assigns(List<String>, boolean, boolean) - Method in class org.apache.hadoop.hbase.client.HBaseHbck
- assigns(List<String>, boolean, 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 class 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
- asyncClusterConnection - Variable in class org.apache.hadoop.hbase.HBaseServerBase
-
The asynchronous cluster connection to be shared by services.
- org.apache.hadoop.hbase.client.AsyncClusterConnection - Interface in org.apache.hadoop.hbase.client
-
The asynchronous connection for internal usage.
- 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, SocketAddress, User) - Constructor for class org.apache.hadoop.hbase.client.AsyncConnectionImpl
- AsyncConnectionImpl(Configuration, ConnectionRegistry, String, SocketAddress, 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, Abortable, Path, String, String, Configuration, List<WALActionsListener>, boolean, String, String, FileSystem, Path, 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.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.AsyncRegionReplicationRetryingCaller - Class in org.apache.hadoop.hbase.client
-
For replicating edits to secondary replicas.
- AsyncRegionReplicationRetryingCaller(HashedWheelTimer, AsyncClusterConnectionImpl, int, long, long, RegionInfo, List<WAL.Entry>) - Constructor for class org.apache.hadoop.hbase.client.AsyncRegionReplicationRetryingCaller
- org.apache.hadoop.hbase.client.AsyncRegionServerAdmin - Class in org.apache.hadoop.hbase.client
-
A simple wrapper of the
AdminProtos.AdminService
for a region server, which returns aCompletableFuture
. - 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 3.0.0, will be removed in 4.0.0. For internal test use only, do not use it any more.
- org.apache.hadoop.hbase.client.AsyncTable.CheckAndMutateWithFilterBuilder - Interface in org.apache.hadoop.hbase.client
-
Deprecated.Since 3.0.0, will be removed in 4.0.0. For internal test use only, do not use it any more.
- org.apache.hadoop.hbase.client.AsyncTable.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.AsyncTable.PartialResultCoprocessorCallback<S,
R> - Interface in org.apache.hadoop.hbase.client -
Some coprocessors may support the idea of "partial results." If for some reason a coprocessor cannot return all results for a given region in a single response, the client side can be designed to recognize this and continuing requesting more results until they are completely accumulated in the client.
- 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
- 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.
- attachCompletionAction(Runnable) - Method in class org.apache.hadoop.hbase.regionserver.MultiVersionConcurrencyControl.WriteEntry
- 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 class 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
- org.apache.hadoop.hbase.http.lib.AuthenticationFilterInitializer - Class in org.apache.hadoop.hbase.http.lib
-
This class is copied from Hadoop.
- AuthenticationFilterInitializer() - Constructor for class org.apache.hadoop.hbase.http.lib.AuthenticationFilterInitializer
- authenticationMethod - Variable in enum class 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 Class in org.apache.hadoop.hbase.security
-
Authentication method
- AUTHORIZATION - Enum constant in enum class 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(int) - Static method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Checks to see if a specific port is available.
- 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
- await(long, BooleanSupplier) - Static method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Await the successful return of
condition
, sleepingsleepMillis
between invocations. - 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 class 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 class 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 Class 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 Class 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 Class 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 Class in org.apache.hadoop.hbase.backup
- backwardSeek(ExtendedCell) - 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(ExtendedCell) - Method in class org.apache.hadoop.hbase.regionserver.NonReversedNonLazyKeyValueScanner
- backwardSeek(ExtendedCell) - Method in class org.apache.hadoop.hbase.regionserver.ReversedKeyValueHeap
- backwardSeek(ExtendedCell) - Method in class org.apache.hadoop.hbase.regionserver.ReversedStoreScanner
- backwardSeek(ExtendedCell) - 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(ExtendedCell) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
- BAD_FAMILY - Enum constant in enum class 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.master.HMaster
- balance(RpcController, MasterProtos.BalanceRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- BALANCE_DECISION - Enum constant in enum class org.apache.hadoop.hbase.namequeues.NamedQueuePayload.NamedQueueEvent
- BALANCE_REJECTION - Enum constant in enum class 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_DECISION_EVENT - Static variable in class org.apache.hadoop.hbase.namequeues.BalancerDecisionDetails
- BALANCER_ON - Enum constant in enum class 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.client.Admin
-
Balance regions in the given RegionServer group
- balanceRSGroup(String) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Balance regions in the given RegionServer group
- balanceRSGroup(String, BalanceRequest) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Balance regions in the given RegionServer group, running based on the given
BalanceRequest
. - balanceRSGroup(String, BalanceRequest) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Balance regions in the given RegionServer group
- balanceRSGroup(String, BalanceRequest) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminClient
-
Deprecated.Balance regions in the given RegionServer group.
- balanceRSGroup(String, BalanceRequest) - Method in interface org.apache.hadoop.hbase.rsgroup.RSGroupInfoManager
-
Balance a region server group.
- balanceRSGroup(RpcController, RSGroupAdminProtos.BalanceRSGroupRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- 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.
- 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
- BASE_TEST_DIRECTORY_KEY - Static variable in class org.apache.hadoop.hbase.HBaseCommonTestingUtility
-
Deprecated.System property key to get base test directory value
- 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 theBaseConfigurable.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
-
Base implementation for
Codec.Decoder
. - 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
ReplicationEndpoint
s. - BaseReplicationEndpoint() - Constructor for class org.apache.hadoop.hbase.replication.BaseReplicationEndpoint
- 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 class 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 interface org.apache.hadoop.hbase.client.Table
-
Method that does a batch call on Deletes, Gets, Puts, Increments, Appends, RowMutations.
- BATCH_COUNT_CAPACITY - Static variable in class org.apache.hadoop.hbase.regionserver.regionreplication.RegionReplicationSink
- BATCH_COUNT_CAPACITY_DEFAULT - Static variable in class org.apache.hadoop.hbase.regionserver.regionreplication.RegionReplicationSink
- BATCH_GET_KEY - Static variable in interface org.apache.hadoop.hbase.thrift.MetricsThriftServerSource
- BATCH_LIMIT_REACHED - Enum constant in enum class org.apache.hadoop.hbase.regionserver.ScannerContext.NextState
- BATCH_MUTATE - Enum constant in enum class 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.
- BATCH_SIZE_CAPACITY - Static variable in class org.apache.hadoop.hbase.regionserver.regionreplication.RegionReplicationSink
- BATCH_SIZE_CAPACITY_DEFAULT - Static variable in class org.apache.hadoop.hbase.regionserver.regionreplication.RegionReplicationSink
- 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 interface org.apache.hadoop.hbase.client.Table
-
Deprecated.since 3.0.0, will removed in 4.0.0. Please use the batch related methods in
AsyncTable
directly if you want to use callback. We reuse the callback for coprocessor here, and the problem is that for batch operation, theAsyncTable
does not tell us the region, so in this method we need an extra locating after we get the result, which is not good. - batchCoprocessorService(Descriptors.MethodDescriptor, Message, byte[], byte[], R) - Method in interface org.apache.hadoop.hbase.client.Table
-
Deprecated.since 3.0.0, will removed in 4.0.0. The batch call here references the blocking interface for of a protobuf stub, so it is not possible to do it in an asynchronous way, even if now we are building the
Table
implementation based on theAsyncTable
, which is not good. Use the coprocessorService methods inAsyncTable
directly instead. - batchCoprocessorService(Descriptors.MethodDescriptor, Message, byte[], byte[], R, Batch.Callback<R>) - Method in interface org.apache.hadoop.hbase.client.Table
-
Deprecated.since 3.0.0, will removed in 4.0.0. The batch call here references the blocking interface for of a protobuf stub, so it is not possible to do it in an asynchronous way, even if now we are building the
Table
implementation based on theAsyncTable
, which is not good. Use the coprocessorService methods inAsyncTable
directly instead. - BATCHES - Enum constant in enum class 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
- 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
- batchUpdateHFileRefs(String, List<String>) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueueStorage
-
Add the given hfile refs to the given peer.
- batchUpdateHFileRefs(String, List<String>) - Method in class org.apache.hadoop.hbase.replication.TableReplicationQueueStorage
- batchUpdateLastSequenceIds(List<ZKReplicationQueueStorageForMigration.ZkLastPushedSeqId>) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueueStorage
-
Update last pushed sequence id for the given regions and peers.
- batchUpdateLastSequenceIds(List<ZKReplicationQueueStorageForMigration.ZkLastPushedSeqId>) - Method in class org.apache.hadoop.hbase.replication.TableReplicationQueueStorage
- batchUpdateQueues(ServerName, List<ReplicationQueueData>) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueueStorage
-
Update the replication queue datas for a given region server.
- batchUpdateQueues(ServerName, List<ReplicationQueueData>) - Method in class org.apache.hadoop.hbase.replication.TableReplicationQueueStorage
- 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 class 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.
- beforeMutate(long, Mutation) - Method in class org.apache.hadoop.hbase.util.LoadTestDataGeneratorWithTags
- 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
- begin() - Method in class org.apache.hadoop.hbase.regionserver.MultiVersionConcurrencyControl
-
Call
MultiVersionConcurrencyControl.begin(Runnable)
with an emptyRunnable
. - begin(Runnable) - Method in class org.apache.hadoop.hbase.regionserver.MultiVersionConcurrencyControl
-
Start a write transaction.
- BEGIN - Static variable in class org.apache.hadoop.hbase.replication.ReplicationGroupOffset
- 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 class 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 class 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(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
- Binomial(Random, int, int, double) - Constructor for class org.apache.hadoop.hbase.util.RandomDistribution.Binomial
-
Generate random integers from min (inclusive) to max (exclusive) following Binomial distribution.
- 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 Class 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 class 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_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
- BlockCacheKey(Path, 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 aFuture
-likeBlockingRpcCallback.get()
method, which will block util the instance'sBlockingRpcCallback.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 Class 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'.
- org.apache.hadoop.hbase.io.hfile.BlockType - Enum Class in org.apache.hadoop.hbase.io.hfile
-
Various types of HFile blocks.
- org.apache.hadoop.hbase.io.hfile.BlockType.BlockCategory - Enum Class 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, ExtendedCell) - 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 class org.apache.hadoop.hbase.io.hfile.BlockType.BlockCategory
- BLOOM_AND_COMPRESSION_COMBINATIONS - Static variable in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- BLOOM_CHUNK - Enum constant in enum class 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
- 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
- bloomType - Variable in class org.apache.hadoop.hbase.util.LoadTestTool
- org.apache.hadoop.hbase.regionserver.BloomType - Enum Class in org.apache.hadoop.hbase.regionserver
- BLUE - Enum constant in enum class 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 class org.apache.hadoop.hbase.util.PrettyPrinter.Unit
- BOOLEAN_PARAMETERIZED - Static variable in class org.apache.hadoop.hbase.HBaseCommonTestingUtility
-
Deprecated.This is for unit tests parameterized with a two booleans.
- 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(AsyncClusterConnection, 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 class 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
HFile
s. - 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 class 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 - Static variable in interface org.apache.hadoop.hbase.rest.ProtobufMessageHandler
- 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.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 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 class org.apache.hadoop.hbase.StartMiniClusterOption.Builder
-
Deprecated.
- 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, 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, long) - 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.StartMiniClusterOption
-
Deprecated.Returns a new builder.
- 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
- 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
- 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
- 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
- buildMoveServersRequest(Set<Address>, String) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
- 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<ExtendedCellScannable>, 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
- 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
- buildRemoveServersRequest(Set<Address>) - 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
- buildTransitReplicationPeerSyncReplicationStateRequest(String, SyncReplicationState) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
- 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(TableName, List<Pair<byte[], String>>, byte[], boolean, Token<?>, String, boolean, List<String>, boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncClusterConnection
-
Securely bulk load a list of HFiles, passing additional list of clusters ids tracking clusters where the given bulk load has already been processed (important for bulk loading replication).
- 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 class org.apache.hadoop.hbase.Size.Unit
- BYTE - Enum constant in enum class 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[]
usingBytes.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 a nio ByteBuffer pool.
- 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 byByteBuffer
- 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
-
Utility functions for working with byte buffers, such as reading/writing variable-length long numbers.
- 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(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 class org.apache.hadoop.hbase.snapshot.ExportSnapshot.Counter
- BYTES_EXPECTED - Enum constant in enum class 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 class 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 class 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_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_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_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_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
- 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
- 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.HBaseServerBase
- cacheTableDescriptor() - Method in class org.apache.hadoop.hbase.master.HMaster
- cacheTableDescriptor() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
- 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.
- 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.
- calculateCellsSize(List<Cell>) - Static method in class org.apache.hadoop.hbase.quotas.QuotaUtil
- 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 class 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(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.MasterRegistry
- 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(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
- 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
- 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
- callWithVersion(VersionInfoUtil.ServiceCallFunction<T1, T2, R, E>, T1, T2) - Static method in class org.apache.hadoop.hbase.client.VersionInfoUtil
- 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 class org.apache.hadoop.hbase.ScheduledChore
- 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 class 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(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.HBaseServerBase
- 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 class org.apache.hadoop.hbase.regionserver.HRegion.FlushResult.Result
- CANNOT_FLUSH_MEMSTORE_EMPTY - Enum constant in enum class 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.HBaseServerBase
- 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>, ExtendedCell) - Static method in class org.apache.hadoop.hbase.TagUtil
-
Add to
tagsOrNull
any Tagscell
is carrying or null if none. - carryForwardTags(ExtendedCell) - 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
- org.apache.hadoop.hbase.CatalogFamilyFormat - Class in org.apache.hadoop.hbase
-
Helper class for generating/parsing "info" family cells in meta table.
- CatalogFamilyFormat() - Constructor for class org.apache.hadoop.hbase.CatalogFamilyFormat
- 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.
- org.apache.hadoop.hbase.CatalogReplicaMode - Enum Class in org.apache.hadoop.hbase
-
There are two modes with catalog replica support.
- ceiling(T) - Method in class org.apache.hadoop.hbase.regionserver.CellSet
- ceilingEntry(K) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
- ceilingEntry(T) - Method in class org.apache.hadoop.hbase.regionserver.CellFlatMap
- ceilingKey(K) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
- ceilingKey(T) - 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 class 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 class 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 Class 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
, andImmutableSegment
. - 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<T extends org.apache.hadoop.hbase.Cell> - Class in org.apache.hadoop.hbase.regionserver
-
CellArrayMap is a simple array of Cells and cannot be allocated off-heap.
- CellArrayMap(Comparator<? super T>, T[], 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 Class in org.apache.hadoop.hbase
-
Used by
CellBuilderFactory
andExtendedCellBuilderFactory
. - org.apache.hadoop.hbase.regionserver.CellChunkImmutableSegment - Class in org.apache.hadoop.hbase.regionserver
-
CellChunkImmutableSegment extends the API supported by a
Segment
, andImmutableSegment
. - 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<T extends org.apache.hadoop.hbase.Cell> - 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 T>, 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<T extends org.apache.hadoop.hbase.Cell> - Class in org.apache.hadoop.hbase.regionserver
-
CellFlatMap stores a constant number of elements and is immutable after creation stage.
- CellFlatMap(Comparator<? super T>, 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 class 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 class 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
Cell
s - cellScanner() - Method in class org.apache.hadoop.hbase.client.Mutation
-
For client users: You should only use the return value as a
CellScanner
,ExtendedCellScanner
is marked as IA.Private which means there is no guarantee about its API stability. - cellScanner() - Method in class org.apache.hadoop.hbase.client.Result
-
For client users: You should only use the return value as a
CellScanner
,ExtendedCellScanner
is marked as IA.Private which means there is no guarantee about its API stability. - cellScanner() - Method in interface org.apache.hadoop.hbase.ExtendedCellScannable
- 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
- 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<T extends org.apache.hadoop.hbase.Cell> - Class in org.apache.hadoop.hbase.regionserver
-
A
Set
ofCell
s, 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
- org.apache.hadoop.hbase.replication.ChainWALEmptyEntryFilter - Class in org.apache.hadoop.hbase.replication
-
A
ChainWALEntryFilter
for providing more flexible options - ChainWALEmptyEntryFilter(List<WALEntryFilter>) - Constructor for class org.apache.hadoop.hbase.replication.ChainWALEmptyEntryFilter
- ChainWALEmptyEntryFilter(WALEntryFilter...) - Constructor for class org.apache.hadoop.hbase.replication.ChainWALEmptyEntryFilter
- 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
-
This is a wrapper around
ReadableByteChannel.read(java.nio.ByteBuffer)
. - 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 class 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
againstthis
policy. - CHECK - Enum constant in enum class 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 class org.apache.hadoop.hbase.quotas.OperationQuota.OperationType
- CHECK_AND_MUTATE - Enum constant in enum class 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.
- 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 3.0.0, will be removed in 4.0.0. For internal test use only, do not use it any more.
- checkAndMutate(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.client.Table
-
Deprecated.Since 3.0.0, will be removed in 4.0.0. For internal test use only, do not use it any more.
- checkAndMutate(byte[], byte[], byte[], CompareOperator, ByteArrayComparable, Mutation) - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Deprecated.since 3.0.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 3.0.0 and will be removed in 4.0.0. Use
Region.checkAndMutate(CheckAndMutate)
instead. - checkAndMutate(byte[], Filter) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
Deprecated.Since 3.0.0, will be removed in 4.0.0. For internal test use only, do not use it any more.
- checkAndMutate(byte[], Filter) - Method in interface org.apache.hadoop.hbase.client.Table
-
Deprecated.Since 3.0.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 3.0.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 3.0.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 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 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(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 3.0.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 3.0.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 3.0.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 3.0.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, int, int) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment
-
Check the quota for the current (rpc-context) user.
- checkBatchQuota(Region, int, int) - Method in class org.apache.hadoop.hbase.quotas.RegionServerRpcQuotaManager
-
Check the quota for the current (rpc-context) user.
- checkBatchQuota(Region, int, int) - Method in interface org.apache.hadoop.hbase.quotas.RpcQuotaManager
-
Check the quota for the current (rpc-context) user.
- checkBatchQuota(Region, List<ClientProtos.Action>, boolean) - Method in class org.apache.hadoop.hbase.quotas.RegionServerRpcQuotaManager
- checkBatchQuota(Region, List<ClientProtos.Action>, boolean) - Method in interface org.apache.hadoop.hbase.quotas.RpcQuotaManager
-
Check the quota for the current (rpc-context) user.
- checkBatchQuota(Region, OperationQuota.OperationType) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment
-
Check the quota for the current (rpc-context) user.
- checkBatchQuota(Region, OperationQuota.OperationType) - Method in class org.apache.hadoop.hbase.quotas.RegionServerRpcQuotaManager
- checkBatchQuota(Region, OperationQuota.OperationType) - Method in interface org.apache.hadoop.hbase.quotas.RpcQuotaManager
-
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(ExtendedCell, 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(ExtendedCell, 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(ExtendedCell, byte) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.NewVersionBehaviorTracker
- checkColumn(ExtendedCell, 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, ExtendedCell) - 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.
- 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'
- checkHasDataInQueues() - Method in class org.apache.hadoop.hbase.util.hbck.ReplicationChecker
- 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.
- 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.
- 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 class org.apache.hadoop.hbase.HBaseRpcServicesBase
-
Check if an OOME and, if so, abort immediately to avoid creating more objects.
- checkOOME(Throwable) - Method in interface org.apache.hadoop.hbase.ipc.HBaseRPCErrorHandler
-
Take actions on the event of an OutOfMemoryError.
- 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.
- 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(ExtendedCell) - 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(Scan, long, long) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment
-
Check the quota for the current (rpc-context) user.
- checkScanQuota(Region, ClientProtos.ScanRequest, long, long, long) - Method in class org.apache.hadoop.hbase.quotas.RegionServerRpcQuotaManager
- checkScanQuota(Region, ClientProtos.ScanRequest, long, long, long) - Method in interface org.apache.hadoop.hbase.quotas.RpcQuotaManager
-
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
- checkSlowSyncCount() - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
- checkSlowSyncCount() - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
- 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.
- 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.
- checksumRows(Table) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Return an md5 digest of the entire contents of a table.
- org.apache.hadoop.hbase.util.ChecksumType - Enum Class 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
- checkTimestamp(long) - Method in class org.apache.hadoop.hbase.client.Mutation
- 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(ExtendedCell, 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(ExtendedCell, long, byte, boolean) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ExplicitColumnTracker
- checkVersions(ExtendedCell, long, byte, boolean) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.NewVersionBehaviorTracker
- checkVersions(ExtendedCell, 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.
- chooseSinks() - Method in class org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint
- chore() - Method in class org.apache.hadoop.hbase.ExecutorStatusChore
- 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
- choreService - Variable in class org.apache.hadoop.hbase.HBaseServerBase
-
ChoreService used to schedule tasks that we want to run periodically
- 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 class 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 Class in org.apache.hadoop.hbase.regionserver
-
Types of chunks, based on their sizes
- cipher - Variable in class org.apache.hadoop.hbase.util.LoadTestTool
- 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.
- claim(ServerName) - Method in class org.apache.hadoop.hbase.replication.ReplicationQueueId
- claimQueue(ReplicationQueueId, 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.
- claimQueue(ReplicationQueueId, ServerName) - Method in class org.apache.hadoop.hbase.replication.TableReplicationQueueStorage
- 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
-
Deprecated.Since 3.0.0, will be removed in 4.0.0. For internal test use only, do not use it any more.
- org.apache.hadoop.hbase.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.
- cleanExpiredMobFiles(FileSystem, Configuration, TableDescriptor, ColumnFamilyDescriptor, CacheConfig, long) - Static method in class org.apache.hadoop.hbase.mob.MobUtils
-
Cleans the expired mob files.
- cleanExpiredMobFiles(TableDescriptor, ColumnFamilyDescriptor) - Method in class org.apache.hadoop.hbase.mob.ExpiredMobFileCleaner
-
Cleans the MOB files when they're expired and their min versions are 0.
- 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(HRegion, ClientProtos.CleanupBulkLoadRequest) - Method in class org.apache.hadoop.hbase.regionserver.SecureBulkLoadManager
- cleanupBulkLoad(TableName, String) - Method in interface org.apache.hadoop.hbase.client.AsyncClusterConnection
-
Clean up after finishing bulk load, no matter success or not.
- cleanupBulkLoad(RpcController, ClientProtos.CleanupBulkLoadRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
- cleanupDataTestDirOnTestFS() - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Cleans the test data directory on the test filesystem.
- cleanupDataTestDirOnTestFS(String) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Cleans a subdirectory under the test data directory on the test filesystem.
- 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)
- cleanupTestDir() - Method in class org.apache.hadoop.hbase.HBaseCommonTestingUtility
-
Deprecated.Returns True if we removed the test dirs
- cleanupTestDir() - Method in class org.apache.hadoop.hbase.HBaseZKTestingUtility
-
Deprecated.Returns True if we removed the test dirs
- cleanupTestDir(String) - Method in class org.apache.hadoop.hbase.HBaseCommonTestingUtility
-
Deprecated.
- 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.
- 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
- 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(AdminProtos.ClearCompactionQueuesRequest) - Method in class org.apache.hadoop.hbase.client.AsyncRegionServerAdmin
- clearCompactionQueues(RpcController, AdminProtos.ClearCompactionQueuesRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- 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(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(AdminProtos.ClearRegionBlockCacheRequest) - Method in class org.apache.hadoop.hbase.client.AsyncRegionServerAdmin
- clearRegionBlockCache(RpcController, AdminProtos.ClearRegionBlockCacheRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- clearRegionBlockCache(RpcController, AdminProtos.ClearRegionBlockCacheRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
- 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 interface org.apache.hadoop.hbase.client.RegionLocator
-
Clear all the entries in the region location cache.
- clearRegionLocationCache() - Method in class org.apache.hadoop.hbase.client.SharedAsyncConnection
- clearRegionLocationCache() - Method in class org.apache.hadoop.hbase.client.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
- clearSlowLogsResponses(RpcController, AdminProtos.ClearSlowLogResponseRequest) - Method in class org.apache.hadoop.hbase.HBaseRpcServicesBase
- 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 byHStore#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 This constructor will create an object using the old faulty load balancing logic.
- Client(Cluster, boolean) - Constructor for class org.apache.hadoop.hbase.rest.client.Client
-
Constructor This constructor will create an object using the old faulty load balancing logic.
- 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) This constructor will create an object using the old faulty load balancing logic.
- Client(Cluster, Configuration, boolean) - Constructor for class org.apache.hadoop.hbase.rest.client.Client
-
Constructor This constructor will create an object using the old faulty load balancing logic.
- Client(Cluster, Configuration, boolean, Optional<KeyStore>, Optional<String>, Optional<String>, Optional<String>) - Constructor for class org.apache.hadoop.hbase.rest.client.Client
- Client(Cluster, Configuration, boolean, Optional<KeyStore>, Optional<String>, Optional<String>, Optional<String>, Optional<HttpClientConnectionManager>) - Constructor for class org.apache.hadoop.hbase.rest.client.Client
-
Constructor that accepts an optional trustStore and authentication information for either BASIC or BEARER authentication in sticky mode, which does not use the old faulty load balancing logic, and enables correct session handling.
- 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 class org.apache.hadoop.hbase.hbtop.field.Field
- CLIENT - Enum constant in enum class org.apache.hadoop.hbase.hbtop.mode.Mode
- CLIENT_BOOTSTRAP_NODE_LIMIT - Static variable in class org.apache.hadoop.hbase.HBaseRpcServicesBase
- 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 class 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.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
- org.apache.hadoop.hbase.client.ClientInternalHelper - Class in org.apache.hadoop.hbase.client
-
A helper class used to access the package private field in o.a.h.h.client package.
- ClientInternalHelper() - Constructor for class org.apache.hadoop.hbase.client.ClientInternalHelper
- org.apache.hadoop.hbase.ClientMetaTableAccessor - Class in org.apache.hadoop.hbase
-
The (asynchronous) meta table accessor used at client side.
- org.apache.hadoop.hbase.ClientMetaTableAccessor.CloseableVisitor - Interface in org.apache.hadoop.hbase
-
Implementations 'visit' a catalog table row but with close() at the end.
- org.apache.hadoop.hbase.ClientMetaTableAccessor.QueryType - Enum Class in org.apache.hadoop.hbase
- org.apache.hadoop.hbase.ClientMetaTableAccessor.Visitor - Interface in org.apache.hadoop.hbase
-
Implementations 'visit' a catalog table row.
- 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.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.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.
- cloneContext(HFileContext) - Static method in class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil
- 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(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.
- 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.
- cloneTags() - Method in interface org.apache.hadoop.hbase.RawCell
-
Allows cloning the tags in the cell to a new byte[]
- cloneTags(ExtendedCell) - 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.MasterRegistry
- 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.ClientSideRegionScanner
- close() - Method in interface org.apache.hadoop.hbase.client.Connection
- 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.HBaseHbck
- 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.SharedAsyncConnection
- close() - Method in class org.apache.hadoop.hbase.client.SharedConnection
- 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.HBaseCluster
-
Deprecated.Closes all the resources held open for this cluster.
- 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.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.master.RegionPlacementMaintainer
- close() - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.
- 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.CombinedWriter
- close() - Method in class org.apache.hadoop.hbase.regionserver.wal.CombinedWriterBase
- close() - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogWriter
- close() - Method in class org.apache.hadoop.hbase.rest.client.Client
- 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 interface org.apache.hadoop.hbase.TableDescriptors
- close() - Method in class org.apache.hadoop.hbase.util.CollectionBackedScanner
- close() - Method in class org.apache.hadoop.hbase.util.FSTableDescriptors
- close() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- close() - Method in class org.apache.hadoop.hbase.util.MultiThreadedAction
- close() - Method in class org.apache.hadoop.hbase.util.RegionMover
- close() - Method in class org.apache.hadoop.hbase.wal.AbstractWALProvider
- close() - Method in class org.apache.hadoop.hbase.wal.AbstractWALRoller
- close() - Method in class org.apache.hadoop.hbase.wal.BoundedRecoveredHFilesOutputSink
- 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() - Method in class org.apache.hadoop.hdfs.DummyDFSOutputStream
- close(boolean) - Method in class org.apache.hadoop.hbase.io.HalfStoreFileReader
-
Overrides close method to handle cache evictions for the referred file.
- 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
- close0() - Method in class org.apache.hadoop.hbase.wal.AbstractFSWALProvider
- close0() - Method in class org.apache.hadoop.hbase.wal.AbstractWALProvider
- close0() - Method in class org.apache.hadoop.hbase.wal.RegionGroupingProvider
- 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
- closeClusterConnection() - Method in class org.apache.hadoop.hbase.HBaseServerBase
- closeCompletionService - Variable in class org.apache.hadoop.hbase.wal.BoundedRecoveredHFilesOutputSink
- closeConnection() - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- closeConnection(SimpleServerRpcConnection) - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcServer
-
Deprecated.
- 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 class 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.
- closeHTable() - Method in class org.apache.hadoop.hbase.util.MultiThreadedUpdater.HBaseUpdaterThread
- closeHTable() - Method in class org.apache.hadoop.hbase.util.MultiThreadedUpdaterWithACL.HBaseUpdaterThreadWithACL
- closeHTable() - Method in class org.apache.hadoop.hbase.util.MultiThreadedWriter.HBaseWriterThread
- closeHTable() - Method in class org.apache.hadoop.hbase.util.MultiThreadedWriterWithACL.HBaseWriterThreadWithACL
- 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(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(AdminProtos.CloseRegionRequest) - Method in class org.apache.hadoop.hbase.client.AsyncRegionServerAdmin
- 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.master.MasterRpcServices
- closeRegion(RpcController, AdminProtos.CloseRegionRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
Close a region on the region server.
- closeRegionAndWAL(HRegion) - Static method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Close both the HRegion
r
and it's underlying WAL. - closeRegionAndWAL(Region) - Static method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Close both the region
r
and it's underlying WAL. - 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(AsyncClusterConnection, 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.
- 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)
. - closeTable() - Method in class org.apache.hadoop.hbase.util.MultiThreadedReader.HBaseReaderThread
- closeTable() - Method in class org.apache.hadoop.hbase.util.MultiThreadedReaderWithACL.HBaseReaderThreadWithACL
- closeTableDescriptors() - Method in class org.apache.hadoop.hbase.HBaseServerBase
- closeThreadPool - Variable in class org.apache.hadoop.hbase.wal.BoundedRecoveredHFilesOutputSink
-
Used when close this output sink.
- closeWriter(W, Path) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
- closeZooKeeper() - Method in class org.apache.hadoop.hbase.HBaseServerBase
- CLOSING - Enum constant in enum class 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 class 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 class 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_LOCAL - Static variable in class org.apache.hadoop.hbase.HConstants
-
Cluster is standalone or pseudo-distributed
- CLUSTER_READ_REQUESTS_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
- CLUSTER_REQUESTS_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
- CLUSTER_WRITE_REQUESTS_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
- clusterCompactionQueues - Variable in class org.apache.hadoop.hbase.util.compaction.MajorCompactor
- org.apache.hadoop.hbase.client.ClusterConnectionFactory - Class in org.apache.hadoop.hbase.client
-
The factory for creating
AsyncClusterConnection
. - clusterId - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
- 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 Class in org.apache.hadoop.hbase
-
Kinds of ClusterMetrics
- org.apache.hadoop.hbase.ClusterMetricsBuilder - Class in org.apache.hadoop.hbase
- clusterMode() - Method in class org.apache.hadoop.hbase.HBaseServerBase
- clusterMode() - Method in class org.apache.hadoop.hbase.master.HMaster
- clusterMode() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
- 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.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.HBaseServerBase
- 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.
- clusterTestDir - Variable in class org.apache.hadoop.hbase.HBaseZKTestingUtility
-
Deprecated.Directory (a subdirectory of dataTestDir) used by the dfs cluster if any
- cmd - Variable in class org.apache.hadoop.hbase.util.LoadTestTool
-
This will be removed as we factor out the dependency on command line
- CMD_KEY - Static variable in class org.apache.hadoop.hbase.PerformanceEvaluation.EvaluationMapTask
-
configuration parameter name that contains the command
- cmdLineArgs - Variable in class org.apache.hadoop.hbase.util.AbstractHBaseTool
- cmp(int) - Method in enum class 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 class org.apache.hadoop.hbase.security.AuthMethod
-
The code for this method.
- code2Type(byte) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
- 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 class org.apache.hadoop.hbase.KeyValue.Type
-
Cannot rely on enum ordinals .
- codeToType(byte) - Static method in enum class org.apache.hadoop.hbase.util.ChecksumType
-
Cannot rely on enum ordinals .
- colDescFromHbase(ColumnFamilyDescriptor) - 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<ExtendedCell>) - Constructor for class org.apache.hadoop.hbase.util.CollectionBackedScanner
- CollectionBackedScanner(List<ExtendedCell>, CellComparator) - Constructor for class org.apache.hadoop.hbase.util.CollectionBackedScanner
- CollectionBackedScanner(SortedSet<ExtendedCell>) - Constructor for class org.apache.hadoop.hbase.util.CollectionBackedScanner
- CollectionBackedScanner(SortedSet<ExtendedCell>, CellComparator) - Constructor for class org.apache.hadoop.hbase.util.CollectionBackedScanner
- CollectionBackedScanner(CellComparator, ExtendedCell...) - Constructor for class org.apache.hadoop.hbase.util.CollectionBackedScanner
- 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 Class in org.apache.hadoop.hbase.hbtop.terminal
-
Terminal color definitions.
- COLUMN_DELETED - Enum constant in enum class 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
- COLUMN_ZERO - Static variable in class org.apache.hadoop.hbase.PerformanceEvaluation
- 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.coprocessor.ColumnInterpreter<T,
S, P extends org.apache.hbase.thirdparty.com.google.protobuf.Message, Q extends org.apache.hbase.thirdparty.com.google.protobuf.Message, R extends org.apache.hbase.thirdparty.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 - Static variable in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- 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.regionserver.wal.CombinedAsyncWriter - Class in org.apache.hadoop.hbase.regionserver.wal
-
An
WALProvider.AsyncWriter
wrapper which writes data to a set ofWALProvider.AsyncWriter
instances. - org.apache.hadoop.hbase.io.hfile.CombinedBlockCache - Class in org.apache.hadoop.hbase.io.hfile
-
CombinedBlockCache is an abstraction layer that combines
FirstLevelBlockCache
andBucketCache
. - 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
- org.apache.hadoop.hbase.regionserver.wal.CombinedWriter - Class in org.apache.hadoop.hbase.regionserver.wal
- org.apache.hadoop.hbase.regionserver.wal.CombinedWriterBase<T extends org.apache.hadoop.hbase.wal.WALProvider.WriterBase> - Class in org.apache.hadoop.hbase.regionserver.wal
-
Base class for combined wal writer implementations.
- CombinedWriterBase(ImmutableList<T>) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.CombinedWriterBase
- 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.HBaseTestingUtility
-
Deprecated.Compact all regions in the mini hbase cluster
- compact(boolean) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.Call flushCache on all regions on all participating regionservers.
- 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
-
We are trying to remove / relax the region read lock for compaction.
- 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, boolean) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Compact all of a table's reagion in the mini hbase cluster
- compact(TableName, boolean) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.Call flushCache on all regions of the specified 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[], 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, 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 - Enum constant in enum class 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 class org.apache.hadoop.hbase.regionserver.ScanType
- COMPACT_OPTION - Static variable in class org.apache.hadoop.hbase.thrift.Constants
- COMPACT_REGION - Enum constant in enum class org.apache.hadoop.hbase.regionserver.Region.Operation
- COMPACT_RETAIN_DELETES - Enum constant in enum class org.apache.hadoop.hbase.regionserver.ScanType
- COMPACT_SWITCH - Enum constant in enum class 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 class 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 class 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 Class 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_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 class 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 Class 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(AdminProtos.CompactionSwitchRequest) - Method in class org.apache.hadoop.hbase.client.AsyncRegionServerAdmin
- compactionSwitch(RpcController, AdminProtos.CompactionSwitchRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- 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[], 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(AdminProtos.CompactRegionRequest) - Method in class org.apache.hadoop.hbase.client.AsyncRegionServerAdmin
- compactRegion(RpcController, AdminProtos.CompactRegionRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- 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.
- 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 Class 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_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.mapreduce.Import.CellWritableComparable.CellWritableComparator
- 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, ExtendedCell, 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.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(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.PrefixKeyDeltaEncoder
- compareCommonQualifierPrefix(Cell, Cell, int) - Static method in class org.apache.hadoop.hbase.io.encoding.PrefixKeyDeltaEncoder
- compareCommonRowPrefix(Cell, Cell, int) - Static method in class org.apache.hadoop.hbase.io.encoding.PrefixKeyDeltaEncoder
-
common prefixes
- 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
- 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.
- 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, ExtendedCell) - Method in interface org.apache.hadoop.hbase.io.encoding.DataBlockEncoder.EncodedSeeker
-
Compare the given key against the current key
- compareKey(CellComparator, ExtendedCell) - Method in class org.apache.hadoop.hbase.io.encoding.RowIndexSeekerV1
- compareKey(CellComparator, ExtendedCell) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.EncodedScanner
- compareKey(CellComparator, ExtendedCell) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
- compareKey(TNode, Object) - Method in interface org.apache.hadoop.hbase.util.AvlUtil.AvlKeyComparator
- compareKeyBasedOnColHint(CellComparator, ExtendedCell, ExtendedCell, 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(ExtendedCell, ExtendedCell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher
- compareKeyForNextRow(ExtendedCell, ExtendedCell) - 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.
- org.apache.hadoop.hbase.CompareOperator - Enum Class 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
- 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
- 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(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.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
- 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
- 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
- compareTo(ByteBuffer, int, int, ByteBuffer, int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
- 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(RegionInfo) - Method in interface org.apache.hadoop.hbase.client.RegionInfo
- compareTo(Row) - Method in class org.apache.hadoop.hbase.client.RegionCoprocessorServiceExec
- 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(HRegionLocation) - Method in class org.apache.hadoop.hbase.HRegionLocation
- 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(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(PerformanceEvaluation.RunResult) - Method in class org.apache.hadoop.hbase.PerformanceEvaluation.RunResult
- 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
- 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 Class 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 class org.apache.hadoop.hbase.backup.BackupInfo.BackupState
- COMPLETE - Enum constant in enum class 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 byMultiVersionConcurrencyControl.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 ofHFile
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 theCompoundBloomFilter
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
- compressAlgo - Variable in class org.apache.hadoop.hbase.util.LoadTestTool
- 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_ALGORITHMS - Static variable in class org.apache.hadoop.hbase.HBaseCommonTestingUtility
-
Deprecated.Compression algorithms to use in testing
- COMPRESSION_ALGORITHMS_PARAMETERIZED - Static variable in class org.apache.hadoop.hbase.HBaseCommonTestingUtility
-
Deprecated.Compression algorithms to use in parameterized JUnit 4 tests
- COMPRESSION_COMPACT - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
- COMPRESSION_COMPACT_MAJOR - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
- COMPRESSION_COMPACT_MINOR - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
- COMPRESSION_OVERRIDE_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
- org.apache.hadoop.hbase.io.compress.Compression.Algorithm - Enum Class 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 Class 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, ExtendedCell, 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 currentSpaceQuotaSnapshot
. - 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[], ExtendedCell) - 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
- concurrentReads(Runnable) - Static method in class org.apache.hadoop.hbase.PerformanceEvaluationCommons
- 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.coprocessor.CoprocessorHost
- conf - Variable in class org.apache.hadoop.hbase.HBaseCluster
-
Deprecated.
- conf - Variable in class org.apache.hadoop.hbase.HBaseCommonTestingUtility
-
Deprecated.
- conf - Variable in class org.apache.hadoop.hbase.HBaseServerBase
- 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.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.HBaseReplicationEndpoint
- 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.util.MultiThreadedAction
- conf - Variable in class org.apache.hadoop.hbase.wal.AbstractWALProvider
- 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.HBaseServerBase
-
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(InfoServer) - Method in class org.apache.hadoop.hbase.HBaseServerBase
- configureInfoServer(InfoServer) - Method in class org.apache.hadoop.hbase.master.HMaster
- configureInfoServer(InfoServer) - 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.ipc.ServerCall
- connection - Variable in class org.apache.hadoop.hbase.util.compaction.MajorCompactionTTLRequest
- connection - Variable in class org.apache.hadoop.hbase.util.compaction.MajorCompactor
- connection - Variable in class org.apache.hadoop.hbase.util.MultiThreadedAction
- 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
Connection
s. - ConnectionFactory() - Constructor for class org.apache.hadoop.hbase.client.ConnectionFactory
-
No public c.tors
- 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.ConnectionRegistryEndpoint - Interface in org.apache.hadoop.hbase.client
-
Define the necessary method for carrying
ClientMetaService
. - org.apache.hadoop.hbase.client.ConnectionRegistryFactory - Class in org.apache.hadoop.hbase.client
-
The entry point for creating a
ConnectionRegistry
. - org.apache.hadoop.hbase.client.ConnectionRegistryURIFactory - Interface in org.apache.hadoop.hbase.client
-
For creating different
ConnectionRegistry
implementation. - 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 Class 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
- consumeExecutor - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
- consumer - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
- 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(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).
- containsObserver(ConfigurationObserver) - Method in class org.apache.hadoop.hbase.conf.ConfigurationManager
-
Returns true if contains the observer, for unit test only
- 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.
- containsRow(byte[]) - Method in interface org.apache.hadoop.hbase.client.RegionInfo
-
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
-
Deprecated.Since 3.0.0, will be removed in 4.0.0. The rsgroup information will be stored in the configuration of a table so this will be removed.
- 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(Server, 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 class 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 class 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 palatableKeeperException
. - 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 incid
- 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 class 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.TableState.State) - Static method in enum class 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 class 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
- 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
toProcedureMetrics
. - 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 Class 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 typeC
. - 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
-
Deprecated.Please stop using this class again, as it is too low level, which is part of the rpc framework for HBase. Will be deleted in 4.0.0.
- org.apache.hadoop.hbase.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 aFuture
-likeCoprocessorRpcUtils.BlockingRpcCallback.get()
method, which will block util the instance'sCoprocessorRpcUtils.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
-
Deprecated.since 3.0.0, will removed in 4.0.0. This is too low level, please stop using it any more. Use the coprocessorService methods in
AsyncAdmin
instead. - coprocessorService(byte[]) - Method in interface org.apache.hadoop.hbase.client.Table
-
Deprecated.since 3.0.0, will removed in 4.0.0. This is too low level, please stop using it any more. Use the coprocessorService methods in
AsyncTable
instead. - coprocessorService(Class<T>, byte[], byte[], Batch.Call<T, R>) - Method in interface org.apache.hadoop.hbase.client.Table
-
Deprecated.since 3.0.0, will removed in 4.0.0. The batch call here references the blocking interface for of a protobuf stub, so it is not possible to do it in an asynchronous way, even if now we are building the
Table
implementation based on theAsyncTable
, which is not good. Use the coprocessorService methods inAsyncTable
directly instead. - coprocessorService(Class<T>, byte[], byte[], Batch.Call<T, R>, Batch.Callback<R>) - Method in interface org.apache.hadoop.hbase.client.Table
-
Deprecated.since 3.0.0, will removed in 4.0.0. The batch call here references the blocking interface for of a protobuf stub, so it is not possible to do it in an asynchronous way, even if now we are building the
Table
implementation based on theAsyncTable
, which is not good. Use the coprocessorService methods inAsyncTable
directly instead. - 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>, AsyncTable.PartialResultCoprocessorCallback<S, R>) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
Similar to above.
- 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
-
Deprecated.since 3.0.0, will removed in 4.0.0. This is too low level, please stop using it any more. Use the coprocessorService methods in
AsyncAdmin
instead. - org.apache.hadoop.hbase.coprocessor.CoprocessorService - Interface in org.apache.hadoop.hbase.coprocessor
-
Deprecated.Since 2.0. Will be removed in 3.0
- 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 Class 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 thedest
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 thedest
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 class org.apache.hadoop.hbase.snapshot.ExportSnapshot.Counter
- copyBufferToStream(DataOutput, ByteBuffer, int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Copy data from a buffer to an output stream.
- copyBufferToStream(OutputStream, ByteBuffer, int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
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(ExtendedCell) - Method in class org.apache.hadoop.hbase.regionserver.ImmutableMemStoreLAB
- copyCellInto(ExtendedCell) - Method in interface org.apache.hadoop.hbase.regionserver.MemStoreLAB
-
Allocates slice in this LAB and copy the passed Cell into this area.
- copyCellInto(ExtendedCell) - 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
-
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
-
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
-
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
-
Copy one buffer's whole data to another.
- copyFromBufferToBuffer(ByteBuffer, ByteBuffer, int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
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
-
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
-
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(ExtendedCell) - 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
-
Similar to
Arrays.copyOfRange(byte[], int, int)
- 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
SpaceQuotaSnapshot
s 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(ExtendedCell, byte[], int) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
Copies the tags info into the tag portion of the cell
- copyTagsTo(ExtendedCell, ByteBuffer, int) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
Copies the tags info into the tag portion of the cell
- copyToNewArrays(Collection<ByteRange>) - Static method in class org.apache.hadoop.hbase.util.ByteRangeUtils
- copyToNewByteArray(ExtendedCell) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
- copyToNewKeyValue(ExtendedCell) - 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 Interface 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.metrics.Counter - Interface in org.apache.hadoop.hbase.metrics
-
A mutable number optimized for high concurrency counting.
- countOfRegionServers() - Method in class org.apache.hadoop.hbase.master.ServerManager
-
Returns the count of active regionservers
- countRows(Table) - Static method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Return the number of rows in the given table.
- countRows(Table, byte[]...) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- countRows(Table, Scan) - Static method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- countRows(InternalScanner) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- countRows(Region) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- countRows(Region, Scan) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- countRows(TableName) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Return the number of rows in the given table.
- countServedRegions() - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.Counts the total numbers of regions being served by the currently online region servers by asking each how many regions they have.
- CP_HTD_ATTR_INCLUSION_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
- CP_REQUEST_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- CP_REQUEST_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- CRC32 - Enum constant in enum class org.apache.hadoop.hbase.util.ChecksumType
- CRC32C - Enum constant in enum class 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
fromin
- create(int, DataInput) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
-
Create a KeyValue reading
length
fromin
- 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(URI, Configuration, User) - Method in interface org.apache.hadoop.hbase.client.ConnectionRegistryURIFactory
-
Instantiate the
ConnectionRegistry
using the given parameters. - create(URI, Configuration, User) - Method in class org.apache.hadoop.hbase.client.RpcConnectionRegistryURIFactory
- create(URI, Configuration, User) - Method in class org.apache.hadoop.hbase.client.ZKConnectionRegistryURIFactory
- create(List<? extends Cell>) - Static method in class org.apache.hadoop.hbase.client.Result
-
Instantiate a Result with the specified List of KeyValues.
- create(List<? extends Cell>, Boolean) - Static method in class org.apache.hadoop.hbase.client.Result
- create(List<? extends Cell>, Boolean, boolean) - Static method in class org.apache.hadoop.hbase.client.Result
- create(List<? extends 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 thecellCodecClsName
and CompressionContext, ifcellCodecClsName
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) - Static method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
- 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, TableDescriptor, ColumnFamilyDescriptor, HRegionFileSystem, boolean) - Static method in class org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileTrackerFactory
- 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, StoreFileTracker) - Static method in class org.apache.hadoop.hbase.mob.CachedMobFile
- create(FileSystem, Path, Configuration, CacheConfig, StoreFileTracker) - 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(MasterServices) - Static method in interface org.apache.hadoop.hbase.rsgroup.RSGroupInfoManager
- 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(WALProvider.AsyncWriter, WALProvider.AsyncWriter...) - Static method in class org.apache.hadoop.hbase.regionserver.wal.CombinedAsyncWriter
- create(WALProvider.Writer, WALProvider.Writer...) - Static method in class org.apache.hadoop.hbase.regionserver.wal.CombinedWriter
- 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 class 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
- createAsyncClusterConnection(URI, Configuration, SocketAddress, User) - Static method in class org.apache.hadoop.hbase.client.ClusterConnectionFactory
-
Create a new
AsyncClusterConnection
instance. - createAsyncClusterConnection(Configuration, SocketAddress, User) - Static method in class org.apache.hadoop.hbase.client.ClusterConnectionFactory
-
Create a new
AsyncClusterConnection
instance. - createAsyncClusterConnection(ConnectionRegistryEndpoint, Configuration, SocketAddress, User) - Static method in class org.apache.hadoop.hbase.client.ClusterConnectionFactory
-
Create a new
AsyncClusterConnection
instance to be used at server side where we have aConnectionRegistryEndpoint
. - createAsyncConnection() - Static method in class org.apache.hadoop.hbase.client.ConnectionFactory
-
Call
ConnectionFactory.createAsyncConnection(Configuration)
using default HBaseConfiguration. - createAsyncConnection(URI) - Static method in class org.apache.hadoop.hbase.client.ConnectionFactory
-
Call
ConnectionFactory.createAsyncConnection(URI, Configuration)
using default HBaseConfiguration. - createAsyncConnection(URI, Configuration) - Static method in class org.apache.hadoop.hbase.client.ConnectionFactory
-
Call
ConnectionFactory.createAsyncConnection(Configuration, User)
using the givenconnectionUri
,conf
and a User object created byUserProvider
. - createAsyncConnection(URI, Configuration, User) - Static method in class org.apache.hadoop.hbase.client.ConnectionFactory
-
Create a new AsyncConnection instance using the passed
connectionUri
,conf
anduser
. - createAsyncConnection(URI, Configuration, User, Map<String, byte[]>) - Static method in class org.apache.hadoop.hbase.client.ConnectionFactory
-
Create a new AsyncConnection instance using the passed
connectionUri
,conf
anduser
. - createAsyncConnection(Configuration) - Static method in class org.apache.hadoop.hbase.client.ConnectionFactory
-
Call
ConnectionFactory.createAsyncConnection(Configuration, User)
using the givenconf
and a User object created byUserProvider
. - createAsyncConnection(Configuration, User) - Static method in class org.apache.hadoop.hbase.client.ConnectionFactory
-
Create a new AsyncConnection instance using the passed
conf
anduser
. - 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
anduser
. - 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.
- createAsyncWriter(FileSystem, Path) - Method in class org.apache.hadoop.hbase.regionserver.wal.AsyncFSWAL
- createBackReferenceName(String, String) - Static method in class org.apache.hadoop.hbase.io.HFileLink
-
Create the back reference name
- createBalanceRSGroupRequest(String, BalanceRequest) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
- createBlockCache(Configuration) - Static method in class org.apache.hadoop.hbase.io.hfile.BlockCacheFactory
- createBlockCache(Configuration, Map<String, HRegion>) - 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[], 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(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, 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.
- createCell(ExtendedCell, 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(ExtendedCell, byte[], byte[]) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
- createCell(ExtendedCell, 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.
- 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 ifcells
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
- 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. - createCombinedWriter(WALProvider.AsyncWriter, WALProvider.AsyncWriter) - Method in class org.apache.hadoop.hbase.regionserver.wal.AsyncFSWAL
- createCombinedWriter(WALProvider.Writer, WALProvider.Writer) - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
- createCombinedWriter(W, W) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
- 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
fromAdminProtos.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
fromClusterStatusProtos.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
- 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 class 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(URI) - Static method in class org.apache.hadoop.hbase.client.ConnectionFactory
-
Create a new Connection instance using default HBaseConfiguration.
- createConnection(URI, Configuration) - Static method in class org.apache.hadoop.hbase.client.ConnectionFactory
-
Create a new Connection instance using the passed
conf
instance. - createConnection(URI, Configuration) - Method in class org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint
-
Some implementations of HBaseInterClusterReplicationEndpoint may require instantiate different Connection implementations, or initialize it in a different way, so defining createConnection as protected for possible overridings.
- createConnection(URI, Configuration, ExecutorService) - Static method in class org.apache.hadoop.hbase.client.ConnectionFactory
-
Create a new Connection instance using the passed
conf
instance. - createConnection(URI, Configuration, ExecutorService, User) - Static method in class org.apache.hadoop.hbase.client.ConnectionFactory
-
Create a new Connection instance using the passed
conf
instance. - createConnection(URI, 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(URI, Configuration, User) - Static method in class org.apache.hadoop.hbase.client.ConnectionFactory
-
Create a new Connection instance using the passed
conf
instance. - 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.HBaseServerBase
- createConnection(Configuration) - Method in class org.apache.hadoop.hbase.MockRegionServerServices
- 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 class 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 ownNioEventLoopGroup
. - 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
- createExtendedCellScanner(Iterable<ExtendedCell>) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
Returns ExtendedCellScanner interface over
cellIterable
- createExtendedCellScanner(Iterator<ExtendedCell>) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
Returns ExtendedCellScanner interface over
cellIterable
or null ifcells
is null - createExtendedCellScanner(List<? extends ExtendedCellScannable>) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
Returns ExtendedCellScanner interface over
cellIterables
- createExtendedCellScanner(NavigableMap<byte[], List<ExtendedCell>>) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
Flatten the map of cells out under the ExtendedCellScanner
- createExtendedCellScanner(ExtendedCell[]) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
Returns CellScanner interface over
cellArray
- 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
- 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. - createGet(long) - Method in class org.apache.hadoop.hbase.util.MultiThreadedReader.HBaseReaderThread
- 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
toSnapshotProtos.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
- createLocalHRegion(RegionInfo, Configuration, TableDescriptor, WAL) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Create an HRegion that writes to the local tmp dirs with specified wal
- createLocalHRegion(RegionInfo, TableDescriptor) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Create an HRegion that writes to the local tmp dirs.
- createLocalHRegion(TableDescriptor, byte[], byte[]) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Create an HRegion that writes to the local tmp dirs
- createLocalHRegion(TableName, byte[], byte[], Configuration, boolean, Durability, WAL, byte[]...) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Return a region on which you must call
HBaseTestingUtility.closeRegionAndWAL(HRegion)
when done. - createLocalHRegionWithInMemoryFlags(TableName, byte[], byte[], Configuration, boolean, Durability, WAL, boolean[], byte[]...) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- 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
- createMemcachedClient(ConnectionFactory, List<InetSocketAddress>) - Method in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
- createMemStoreCompactor(MemoryCompactionPolicy) - Method in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
- 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(ExtendedCell, byte[], byte[]) - Static method in class org.apache.hadoop.hbase.mob.MobUtils
- createMobRefCell(ExtendedCell, 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.
- createMockRegionServerService() - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Create a stubbed out RegionServerService, mainly for getting FS.
- createMockRegionServerService(RpcServerInterface) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Create a stubbed out RegionServerService, mainly for getting FS.
- createMockRegionServerService(ServerName) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Create a stubbed out RegionServerService, mainly for getting FS.
- createModifyableTableDescriptor(String) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- createModifyableTableDescriptor(TableName, int, int, int, KeepDeletedCells) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- createMultiRegionsInMeta(Configuration, TableDescriptor, byte[][]) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Create rows in hbase:meta for regions of the specified table with the specified start keys.
- createMultiRegionTable(TableName, byte[]) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Create a table with multiple regions.
- createMultiRegionTable(TableName, byte[][]) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Create a table with multiple regions.
- createMultiRegionTable(TableName, byte[][], int) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Create a table with multiple regions.
- createMultiRegionTable(TableName, byte[], int) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Create a table with multiple regions.
- createMultiRegionTable(TableName, int, byte[][]) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Create a table with multiple regions.
- createMutableSegment(Configuration, CellComparator, MemStoreSizing) - Method in class org.apache.hadoop.hbase.regionserver.SegmentFactory
- createNamedQueueRecord() - Method in class org.apache.hadoop.hbase.HBaseServerBase
- createNamedQueueRecord() - Method in class org.apache.hadoop.hbase.master.HMaster
- createNamedQueueRecord() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
- 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.master.MasterRpcServices
- createNamespaceAsync(NamespaceDescriptor) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Create a new namespace.
- createNettyServerRpcConnection(Channel) - Method in class org.apache.hadoop.hbase.ipc.NettyRpcServer
- createNextOnRowCol(ExtendedCell) - 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 theequals
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
forDistributedFileSystem
, and a simple implementation for otherFileSystem
which wraps around aFSDataOutputStream
. - 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 class 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
- createPreSplitLoadTestTable(Configuration, TableDescriptor, ColumnFamilyDescriptor) - Static method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Creates a pre-split table for load testing.
- createPreSplitLoadTestTable(Configuration, TableDescriptor, ColumnFamilyDescriptor) - Static method in class org.apache.hadoop.hbase.util.LoadTestUtil
-
Creates a pre-split table for load testing.
- createPreSplitLoadTestTable(Configuration, TableDescriptor, ColumnFamilyDescriptor[], int) - Static method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Creates a pre-split table for load testing.
- createPreSplitLoadTestTable(Configuration, TableDescriptor, ColumnFamilyDescriptor[], int) - Static method in class org.apache.hadoop.hbase.util.LoadTestUtil
-
Creates a pre-split table for load testing.
- createPreSplitLoadTestTable(Configuration, TableDescriptor, ColumnFamilyDescriptor[], RegionSplitter.SplitAlgorithm, int) - Static method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Creates a pre-split table for load testing.
- createPreSplitLoadTestTable(Configuration, TableDescriptor, ColumnFamilyDescriptor[], RegionSplitter.SplitAlgorithm, int) - Static method in class org.apache.hadoop.hbase.util.LoadTestUtil
-
Creates a pre-split table for load testing.
- createPreSplitLoadTestTable(Configuration, TableDescriptor, ColumnFamilyDescriptor, int) - Static method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Creates a pre-split table for load testing.
- createPreSplitLoadTestTable(Configuration, TableDescriptor, ColumnFamilyDescriptor, int) - Static method in class org.apache.hadoop.hbase.util.LoadTestUtil
-
Creates a pre-split table for load testing.
- createPreSplitLoadTestTable(Configuration, TableName, byte[][], Compression.Algorithm, DataBlockEncoding, int, int, Durability) - Static method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Creates a pre-split table for load testing.
- createPreSplitLoadTestTable(Configuration, TableName, byte[][], Compression.Algorithm, DataBlockEncoding, int, int, Durability) - Static method in class org.apache.hadoop.hbase.util.LoadTestUtil
-
Creates a pre-split table for load testing.
- createPreSplitLoadTestTable(Configuration, TableName, byte[], Compression.Algorithm, DataBlockEncoding) - Static method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Creates a pre-split table for load testing.
- createPreSplitLoadTestTable(Configuration, TableName, byte[], Compression.Algorithm, DataBlockEncoding) - Static method in class org.apache.hadoop.hbase.util.LoadTestUtil
-
Creates a pre-split table for load testing.
- createPreSplitLoadTestTable(Configuration, TableName, byte[], Compression.Algorithm, DataBlockEncoding, int, int, Durability) - Static method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Creates a pre-split table for load testing.
- createPreSplitLoadTestTable(Configuration, TableName, byte[], Compression.Algorithm, DataBlockEncoding, int, int, Durability) - Static method in class org.apache.hadoop.hbase.util.LoadTestUtil
-
Creates a pre-split table for load testing.
- createPriority() - Method in class org.apache.hadoop.hbase.HBaseRpcServicesBase
- 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 in a byte array.
- 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
fromSnapshotType
- createRandomTable(TableName, Collection<String>, int, int, int, int, int) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Creates a random table with the given parameters
- 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.
- createReaderThread(int) - Method in class org.apache.hadoop.hbase.util.MultiThreadedReader
- 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
- createReference(Reference, Path) - Method in interface org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileTracker
- 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
- createRegionAndWAL(RegionInfo, Path, Configuration, TableDescriptor) - Static method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Create a region with it's own WAL.
- createRegionAndWAL(RegionInfo, Path, Configuration, TableDescriptor, boolean) - Static method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Create a region with it's own WAL.
- createRegionAndWAL(RegionInfo, Path, Configuration, TableDescriptor, BlockCache) - Static method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Create a region with it's own WAL.
- createRegionAndWAL(RegionInfo, Path, Configuration, TableDescriptor, MobFileCache) - Static method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Create a region with it's own WAL.
- 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[], int, 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 interface org.apache.hadoop.hbase.client.RegionInfo
-
Make a region name of passed parameters.
- 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[], String, boolean) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Make a region name of passed parameters.
- 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
- createRemoteWAL(RegionInfo, FileSystem, Path, String, String) - Method in class org.apache.hadoop.hbase.wal.AbstractFSWALProvider
- createRemoteWAL(RegionInfo, FileSystem, Path, String, String) - Method in class org.apache.hadoop.hbase.wal.AbstractWALProvider
- createRemoteWAL(RegionInfo, FileSystem, Path, String, String) - Method in class org.apache.hadoop.hbase.wal.AsyncFSWALProvider
- createRemoteWAL(RegionInfo, FileSystem, Path, String, String) - Method in class org.apache.hadoop.hbase.wal.FSHLogProvider
- createRemoteWAL(RegionInfo, FileSystem, Path, String, String) - Method in class org.apache.hadoop.hbase.wal.RegionGroupingProvider
- createReplicationMarkerEdit(byte[], long) - Static method in class org.apache.hadoop.hbase.wal.WALEdit
-
Creates a replication tracker edit with
WALEdit.METAFAMILY
family andWALEdit.REPLICATION_MARKER
qualifier and has null value. - createReplicationQueueTableDescriptor(TableName) - Static method in class org.apache.hadoop.hbase.replication.ReplicationStorageFactory
- 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
- createResult(ExtendedCell[]) - Static method in class org.apache.hadoop.hbase.client.ClientInternalHelper
- createResult(ExtendedCell[], Boolean, boolean, boolean) - Static method in class org.apache.hadoop.hbase.client.ClientInternalHelper
- createRootDir() - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Same as
HBaseTestingUtility.createRootDir(boolean create)
except thatcreate
flag is false. - createRootDir(boolean) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Creates an hbase rootdir in user home directory.
- createRootDir(boolean) - Method in class org.apache.hadoop.hbase.StartMiniClusterOption.Builder
-
Deprecated.
- createRootDir(boolean) - Method in class org.apache.hadoop.hbase.testing.TestingHBaseClusterOption.Builder
- createRowModelFromResult(Result) - Static method in class org.apache.hadoop.hbase.rest.RestUtil
-
Speed-optimized method to convert an HBase result to a RowModel.
- 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.regionserver.RSRpcServices
- createRpcServices() - Method in class org.apache.hadoop.hbase.HBaseServerBase
- 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 inTableInputFormat
. - 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
- 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.
- createSingleThreadPoolConsumeExecutor(String, Path, String) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
- 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
toSnapshotDescription
- createSnapshotType(SnapshotProtos.SnapshotDescription.Type) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Creates
SnapshotType
from theSnapshotProtos.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
- createStoreFileInfoForHFile(Configuration, FileSystem, Path, boolean) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
- 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
-
To be used by base (CellFlatMap) class only to create a sub-CellFlatMap Should be used only to create only CellChunkMap from CellChunkMap
- createSubCellFlatMap(int, int, boolean) - Method in class org.apache.hadoop.hbase.regionserver.CellFlatMap
- createSubDir(String, Path, String) - Method in class org.apache.hadoop.hbase.HBaseCommonTestingUtility
-
Deprecated.
- 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() - Method in class org.apache.hadoop.hbase.util.MultiThreadedReader.HBaseReaderThread
- createTable() - Method in class org.apache.hadoop.hbase.util.MultiThreadedReaderWithACL.HBaseReaderThreadWithACL
- createTable() - Method in class org.apache.hadoop.hbase.util.MultiThreadedUpdater.HBaseUpdaterThread
- createTable() - Method in class org.apache.hadoop.hbase.util.MultiThreadedUpdaterWithACL.HBaseUpdaterThreadWithACL
- createTable() - Method in class org.apache.hadoop.hbase.util.MultiThreadedWriter.HBaseWriterThread
- createTable() - Method in class org.apache.hadoop.hbase.util.MultiThreadedWriterWithACL.HBaseWriterThreadWithACL
- 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[][]) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Create a table.
- createTable(TableDescriptor, byte[][], byte[][], Configuration) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Create a table.
- createTable(TableDescriptor, byte[][], byte[][], BloomType, int, Configuration) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Create a table.
- 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[][], Configuration) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Create a table.
- 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(TableName, byte[]) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Create a table.
- createTable(TableName, byte[][]) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Create a table.
- createTable(TableName, byte[][], byte[][]) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Create a table.
- createTable(TableName, byte[][], byte[][], int) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Create a table.
- createTable(TableName, byte[][], byte[][], int, Configuration) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Create a table.
- createTable(TableName, byte[][], int) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Create a table.
- createTable(TableName, byte[][], int[]) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Create a table.
- createTable(TableName, byte[][], int, byte[][]) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Create a table.
- createTable(TableName, byte[][], int, byte[], byte[], int) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- createTable(TableName, byte[][], int, int) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Create a table.
- createTable(TableName, byte[][], int, int, String) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- createTable(TableName, byte[], byte[][]) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Create a table.
- createTable(TableName, byte[], int) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Create a table.
- createTable(TableName, String) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Create a table.
- createTable(TableName, String[]) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Create a table.
- 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, 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.
- 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.
- createTableDescriptor(TableName) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Create a table of name
name
. - createTableDescriptor(TableName, byte[]) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- createTableDescriptor(TableName, byte[][], int) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- createTableDescriptor(TableName, int, int, int, KeepDeletedCells) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- 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.
- createTestRegion(String, ColumnFamilyDescriptor) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- createTestRegion(String, ColumnFamilyDescriptor, BlockCache) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- 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(Configuration, Path, RegionInfo) - Static method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Create an unmanaged WAL.
- 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.StartMiniClusterOption.Builder
-
Deprecated.
- createWALDir(boolean) - Method in class org.apache.hadoop.hbase.testing.TestingHBaseClusterOption.Builder
- createWALKey(RegionInfo, MultiVersionConcurrencyControl, NavigableMap<byte[], Integer>, Map<String, byte[]>) - Static method in class org.apache.hadoop.hbase.regionserver.wal.WALUtil
- createWALRootDir() - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Creates a hbase walDir in the user's home directory.
- 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.
- createWriteKeysQueue(Configuration) - Method in class org.apache.hadoop.hbase.util.MultiThreadedWriterBase
- 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(FileSystem, Path) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
- createWriterInstance(FileSystem, Path) - Method in class org.apache.hadoop.hbase.regionserver.wal.AsyncFSWAL
- createWriterInstance(FileSystem, 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.
- createWriterThreads(int) - Method in class org.apache.hadoop.hbase.util.MultiThreadedWriter
- createWriterThreads(int) - Method in class org.apache.hadoop.hbase.util.MultiThreadedWriterWithACL
- 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 class 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
, andImmutableSegment
. - 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.
- csm - Variable in class org.apache.hadoop.hbase.HBaseServerBase
- 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
-
For client users: You should only use the return value as a
Cell
,ExtendedCell
is marked as IA.Private which means there is no guarantee about its API stability. - current() - Method in class org.apache.hadoop.hbase.codec.BaseDecoder
- current() - Method in class org.apache.hadoop.hbase.codec.KeyValueCodec.ByteBuffKeyValueDecoder
- current() - Method in interface org.apache.hadoop.hbase.ExtendedCellScanner
- CURRENT_REGION_CACHE_RATIO - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- CURRENT_REGION_CACHE_RATIO_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- 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
- 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() - 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_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 class org.apache.hadoop.hbase.hbtop.terminal.Color
D
- D - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
ASCII code for 'D'
- DAILY - Enum constant in enum class 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 class org.apache.hadoop.hbase.io.hfile.BlockType.BlockCategory
- DATA - Enum constant in enum class 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 interface org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoder
-
Type of encoding used for data blocks in HFile.
- DATA_CHUNK - Enum constant in enum class 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 Class in org.apache.hadoop.hbase.io.encoding
-
Provide access to all data block encoding algorithms.
- dataBlockEncodingAlgo - Variable in class org.apache.hadoop.hbase.util.LoadTestTool
- dataBlockIndexReader - Variable in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
-
Data block index reader keeping the root data index in memory
- dataFs - Variable in class org.apache.hadoop.hbase.HBaseServerBase
- dataGenerator - Variable in class org.apache.hadoop.hbase.util.MultiThreadedAction
- 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.StartMiniClusterOption.Builder
-
Deprecated.
- dataNodeHosts(String[]) - Method in class org.apache.hadoop.hbase.testing.TestingHBaseClusterOption.Builder
- dataRootDir - Variable in class org.apache.hadoop.hbase.HBaseServerBase
- 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 class 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 class 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 buffersrc
. - 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 buffersrc
. - decode(PositionedByteRange, int) - Method in class org.apache.hadoop.hbase.types.RawBytesFixedLength
-
Read a
byte[]
from the buffersrc
. - decode(PositionedByteRange, int) - Method in class org.apache.hadoop.hbase.types.RawBytesTerminated
-
Read a
byte[]
from the buffersrc
. - 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 bufferbuff
. - decodeByte(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedInt8
-
Read a
byte
value from the buffersrc
. - 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 bufferbuff
. - decodeDouble(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedFloat64
-
Read a
double
value from the buffersrc
. - decodeDouble(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedNumeric
-
Read a
double
value from the buffersrc
. - 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 bufferbuff
. - decodeFloat(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedFloat32
-
Read a
float
value from the bufferdst
. - 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 bufferbuff
. - decodeInt(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedInt32
-
Read an
int
value from the buffersrc
. - 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.PrefixKeyDeltaEncoder
- 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 bufferbuff
. - decodeLong(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedInt64
-
Read a
long
value from the buffersrc
. - decodeLong(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedNumeric
-
Read a
long
value from the buffersrc
. - 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 bufferbuff
. - decodeShort(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedInt16
-
Read a
short
value from the buffersrc
. - 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
- DECOMMISSIONED_SERVERS - Enum constant in enum class org.apache.hadoop.hbase.ClusterMetrics.Option
-
metrics about decommissioned region servers
- 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.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.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
- decrease(long) - Method in class org.apache.hadoop.hbase.regionserver.regionreplication.RegionReplicationBufferManager
-
Called after you ship the edits out.
- decrement() - Method in interface org.apache.hadoop.hbase.metrics.Counter
-
Decrement
this
by 1. - decrement(long) - Method in interface org.apache.hadoop.hbase.metrics.Counter
-
Decrement
this
byn
. - 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 class 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
- deepCopy() - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Create a new
ByteRange
with new backing byte[] containing a copy of the content fromthis
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 class org.apache.hadoop.hbase.client.Scan.ReadType
- DEFAULT - Enum constant in enum class org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileTrackerFactory.Trackers
- DEFAULT - Static variable in class org.apache.hadoop.hbase.ipc.HeapByteBufAllocator
- DEFAULT - Static variable in enum class 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_BAD_SINK_THRESHOLD - Static variable in class org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint
-
Default maximum number of times a replication sink can be reported as bad before it will no longer be provided as a sink for replication without the pool of replication sinks being refreshed.
- DEFAULT_BASE_TEST_DIRECTORY - Static variable in class org.apache.hadoop.hbase.HBaseCommonTestingUtility
-
Deprecated.Default base directory for test output.
- DEFAULT_BATCH_SIZE - Static variable in class org.apache.hadoop.hbase.util.MultiThreadedReader
-
Default batch size for multigets
- 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_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.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_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.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_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.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_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.HBaseRpcServicesBase
- 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_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_COMPRESSION - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
Default compression type.
- 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_SIZE - Static variable in class org.apache.hadoop.hbase.util.LoadTestTool
-
The default data size if not specified
- 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_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_ENABLE_HISTORICAL_COMPACTION_FILES - Static variable in class org.apache.hadoop.hbase.regionserver.StoreFileWriter
- 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_ON_CLOSE - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
- DEFAULT_EVICT_ON_SPLIT - 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_EXECUTOR_STATUS_COLLECT_ENABLED - Static variable in class org.apache.hadoop.hbase.HConstants
- 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.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_KEY_WINDOW - Static variable in class org.apache.hadoop.hbase.util.MultiThreadedReader
-
Default "window" size between the last key written by the writer and the key that we attempt to read.
- 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_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_ERRORS - Static variable in class org.apache.hadoop.hbase.util.MultiThreadedReader
-
Default maximum number of read errors to tolerate before shutting down all readers.
- 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_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_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_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_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_NUM_REGIONS_PER_SERVER - Static variable in class org.apache.hadoop.hbase.util.LoadTestTool
- DEFAULT_NUM_THREADS - Static variable in class org.apache.hadoop.hbase.util.LoadTestTool
-
The number of reader/writer threads if not specified
- 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_HEAP_USAGE_THRESHOLD - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
- 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_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_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_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_PER_SERVER - Static variable in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.The default number of regions per regionserver when creating a pre-split table.
- 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_SOURCE_RATIO - Static variable in class org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint
-
Default ratio of the total number of peer cluster region servers to consider replicating to.
- 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_KEY - Static variable in class org.apache.hadoop.hbase.util.LoadTestTool
- 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_NAME - Static variable in class org.apache.hadoop.hbase.util.LoadTestTool
-
Table name to use of not overridden on the command line
- 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
-
Don't use it! This'll get you the wrong path in a secure cluster.
- 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_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_VALUE_LENGTH - Static variable in class org.apache.hadoop.hbase.PerformanceEvaluation
- 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_WAKE_FREQ - Static variable in class org.apache.hadoop.hbase.ExecutorStatusChore
- DEFAULT_WAL_BATCH_SIZE - Static variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
- 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
- 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
- DefaultDataGenerator(byte[]...) - Constructor for class org.apache.hadoop.hbase.util.MultiThreadedAction.DefaultDataGenerator
- DefaultDataGenerator(int, int, int, int, byte[]...) - Constructor for class org.apache.hadoop.hbase.util.MultiThreadedAction.DefaultDataGenerator
- 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.
- defaultReservoirEnabled() - Method in class org.apache.hadoop.hbase.HBaseRpcServicesBase
- defaultReservoirEnabled() - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- defaultReservoirEnabled() - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
- 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.
- deferredLogFlush - Variable in class org.apache.hadoop.hbase.util.LoadTestTool
- 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 class org.apache.hadoop.hbase.util.HbckErrorReporter.ERROR_CODE
-
Deprecated.
- 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
- 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 aHBaseRpcController
. - 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 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 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 class org.apache.hadoop.hbase.Cell.Type
- Delete - Enum constant in enum class org.apache.hadoop.hbase.hbtop.terminal.KeyPress.Type
- Delete - Enum constant in enum class 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 class org.apache.hadoop.hbase.backup.BackupRestoreConstants.BackupCommand
- DELETE - Enum constant in enum class 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 class 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.
- deleteAllData() - Method in class org.apache.hadoop.hbase.replication.ZKReplicationQueueStorageForMigration
- 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[], 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.master.MasterRpcServices
- DeleteColumn - Enum constant in enum class org.apache.hadoop.hbase.Cell.Type
- DeleteColumn - Enum constant in enum class 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.
- DELETED - Enum constant in enum class 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 class org.apache.hadoop.hbase.Cell.Type
- DeleteFamily - Enum constant in enum class 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 class org.apache.hadoop.hbase.Cell.Type
- DeleteFamilyVersion - Enum constant in enum class 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
- 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.master.TableNamespaceManager
- 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.master.MasterRpcServices
- deleteNamespaceAsync(String) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Delete an existing namespace.
- 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.
- deleteNumericRows(Table, byte[], int, int) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- 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.
- 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 class org.apache.hadoop.hbase.mapreduce.WALPlayer.Counter
-
Number of aggregated deletes
- deleteShutdownHook(Runnable) - Static method in class org.apache.hadoop.hbase.util.ShutdownHookManager
- 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(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(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.
- 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) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Drop an existing 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.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.
- deleteTableData(TableName) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Provide an existing table name to truncate.
- deleteTableDescriptors(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSTableDescriptors
- deleteTableIfAny(TableName) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Drop an existing table
- deleteTableQuota(Connection, TableName) - Static method in class org.apache.hadoop.hbase.quotas.QuotaUtil
- 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.
- 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 Class 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
- 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 3.0.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
- 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 class org.apache.hadoop.hbase.util.Order
- DESCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedBlob
-
Deprecated.since 3.0.0 and will b removed in 4.0.0
- DESCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedBlobVar
-
Deprecated.since 3.0.0 and will be removed in 4.0.0
- DESCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedFloat32
-
Deprecated.since 3.0.0 and will be removed in 4.0.0
- DESCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedFloat64
-
Deprecated.since 3.0.0 and will be removed in 4.0.0
- DESCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedInt16
-
Deprecated.since 3.0.0 and will be removed in 4.0.0
- DESCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedInt32
-
Deprecated.since 3.0.0 and will be removed in 4.0.0
- DESCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedInt64
-
Deprecated.since 3.0.0 and will be removed in 4.0.0
- DESCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedInt8
-
Deprecated.since 3.0.0 and will be removed in 4.0.0
- DESCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedNumeric
-
Deprecated.since 3.0.0 and will be removed in 4.0.0
- DESCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedString
-
Deprecated.since 3.0.0 and will be removed in 4.0.0
- DESCENDING - Static variable in class org.apache.hadoop.hbase.types.RawBytes
-
Deprecated.since 3.0.0 and will be removed in 4.0.0
- DESCENDING - Static variable in class org.apache.hadoop.hbase.types.RawString
-
Deprecated.since 3.0.0 and will be removed in 4.0.0
- 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 class 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(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.
- detector - Static variable in class org.apache.hadoop.hbase.nio.RefCnt
- 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
- 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 class org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
- DiffCompressionState() - Constructor for class org.apache.hadoop.hbase.io.encoding.DiffKeyDeltaEncoder.DiffCompressionState
- DIFFERENTCELLVALUES - Enum constant in enum class 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 class 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 class org.apache.hadoop.hbase.quotas.SpaceViolationPolicy
-
Disables the table(s).
- DISABLED - Enum constant in enum class org.apache.hadoop.hbase.client.SnapshotType
- DISABLED - Enum constant in enum class org.apache.hadoop.hbase.client.TableState.State
- DISABLED - Enum constant in enum class 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
- 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.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.
- 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.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.
- disableTableIfNotDisabled(Connection, TableName) - Static method in class org.apache.hadoop.hbase.quotas.QuotaUtil
-
Method to disable a table, if not already disabled.
- 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.
- 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 class org.apache.hadoop.hbase.client.TableState.State
- DISALLOWED_TABLE_NAME - Static variable in class org.apache.hadoop.hbase.TableName
-
One globally disallowed name
- 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 Class 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, ExtendedCell, 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
- 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.AsyncRegionReplicationRetryingCaller
- 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
- doCleanUpResources() - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
- doCleanUpResources() - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
- 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
-
check whether a namespace has already existed.
- 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
- 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
- doInit(WALFactory, Configuration, String) - Method in class org.apache.hadoop.hbase.wal.AbstractFSWALProvider
- doInit(WALFactory, Configuration, String) - Method in class org.apache.hadoop.hbase.wal.AbstractWALProvider
- doInit(WALFactory, Configuration, String) - Method in class org.apache.hadoop.hbase.wal.RegionGroupingProvider
- 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.
- 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 class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination.TaskFinisher.Status
-
task completed successfully
- DONE - Enum constant in enum class org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher.MatchCode
-
Do not include, return current result
- DONE - Enum constant in enum class org.apache.hadoop.hbase.regionserver.SplitLogWorker.TaskExecutor.Status
-
Deprecated.
- DONE_SCAN - Enum constant in enum class 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(ExtendedCell) - 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(ExtendedCell) - 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, ExtendedCell, 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, 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
- 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(long, boolean) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
- doubleEquals(Object) - Method in class org.apache.hadoop.hbase.hbtop.RecordFilter.FilterBuilder
- doubleEquals(FieldValue) - Method in class org.apache.hadoop.hbase.hbtop.RecordFilter.FilterBuilder
- DOWNGRADE_ACTIVE - Enum constant in enum class org.apache.hadoop.hbase.replication.SyncReplicationState
- 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.ScanPerformanceEvaluation
- 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.LoadTestTool
- doWork() - Method in class org.apache.hadoop.hbase.util.RegionMover
- doWriterSync(WALProvider.AsyncWriter, boolean, long) - Method in class org.apache.hadoop.hbase.regionserver.wal.AsyncFSWAL
- doWriterSync(WALProvider.Writer, boolean, long) - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
- doWriterSync(W, boolean, long) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
- 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
-
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 class 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
- org.apache.hadoop.hdfs.DummyDFSOutputStream - Class in org.apache.hadoop.hdfs
-
A dummy DFSOutputStream which is mainly used for lease renewal.
- DummyDFSOutputStream(AsyncFSOutput, DFSClient, String, HdfsFileStatus, EnumSet<CreateFlag>, DataChecksum) - Constructor for class org.apache.hadoop.hdfs.DummyDFSOutputStream
- 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 class org.apache.hadoop.hbase.util.HbckErrorReporter.ERROR_CODE
-
Deprecated.
- DUPE_STARTKEYS - Enum constant in enum class 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 Class in org.apache.hadoop.hbase.client
-
Enum describing the durability guarantees for tables and
Mutation
s 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. - duration - Variable in class org.apache.hadoop.hbase.PerformanceEvaluation.RunResult
- 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 class 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.
- ELAPSED_TIME - Enum constant in enum class org.apache.hadoop.hbase.PerformanceEvaluation.Counter
-
elapsed time
- 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 class 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 class 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_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_HISTORICAL_COMPACTION_FILES - Static variable in class org.apache.hadoop.hbase.regionserver.StoreFileWriter
- 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(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 class org.apache.hadoop.hbase.client.TableState.State
- ENABLED - Enum constant in enum class org.apache.hadoop.hbase.replication.ReplicationPeer.PeerState
- ENABLED_ZNODE_BYTES - Static variable in class org.apache.hadoop.hbase.replication.ZKReplicationPeerStorage
- enableDebug(Class<?>) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.In 2.3.0, will be removed in 4.0.0. Only support changing log level on log4j now as HBase only uses log4j. You should do this by your own as it you know which log framework you are using then set the log level to debug is very easy.
- 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
- 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.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.
- enableRSGroup(Configuration) - Static method in class org.apache.hadoop.hbase.rsgroup.RSGroupUtil
- 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.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.
- enableTableIfNotEnabled(Connection, TableName) - Static method in class org.apache.hadoop.hbase.quotas.QuotaUtil
-
Method to enable a table, if not already enabled.
- 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.
- 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 class 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(ExtendedCell, HFileBlockEncodingContext, DataOutputStream) - Method in class org.apache.hadoop.hbase.io.encoding.PrefixKeyDeltaEncoder
- encode(ExtendedCell, HFileBlockEncodingContext, DataOutputStream) - Method in interface org.apache.hadoop.hbase.io.encoding.DataBlockEncoder
-
Encodes a KeyValue.
- encode(ExtendedCell, HFileBlockEncodingContext, DataOutputStream) - Method in class org.apache.hadoop.hbase.io.encoding.RowIndexCodecV1
- encode(ExtendedCell, HFileBlockEncodingContext, DataOutputStream) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoder
-
Encodes a KeyValue.
- encode(ExtendedCell, HFileBlockEncodingContext, DataOutputStream) - Method in class org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoderImpl
- encode(ExtendedCell, 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
todst
. - encode(PositionedByteRange, byte[], int, int) - Method in class org.apache.hadoop.hbase.types.OrderedBlobVar
-
Write a subset of
val
todst
. - encode(PositionedByteRange, byte[], int, int) - Method in class org.apache.hadoop.hbase.types.RawBytes
-
Write
val
intodst
, respectingvoff
andvlen
. - encode(PositionedByteRange, byte[], int, int) - Method in class org.apache.hadoop.hbase.types.RawBytesFixedLength
-
Write
val
intobuff
, respectingoffset
andlength
. - encode(PositionedByteRange, byte[], int, int) - Method in class org.apache.hadoop.hbase.types.RawBytesTerminated
-
Write
val
intodst
, respectingoffset
andlength
. - 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, CellMessage.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 bufferdst
. - 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 bufferdst
. - encode(ChannelHandlerContext, ByteBuf, ByteBuf) - Method in class org.apache.hadoop.hbase.security.SaslWrapHandler
- 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 bufferbuff
. - encodeByte(PositionedByteRange, byte) - Method in class org.apache.hadoop.hbase.types.OrderedInt8
-
Write instance
val
into bufferdst
. - ENCODED_DATA - Enum constant in enum class 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.
- 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
- 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 bufferbuff
. - encodeDouble(PositionedByteRange, double) - Method in class org.apache.hadoop.hbase.types.OrderedFloat64
-
Write instance
val
into bufferdst
. - encodeDouble(PositionedByteRange, double) - Method in class org.apache.hadoop.hbase.types.OrderedNumeric
-
Write instance
val
into bufferdst
. - 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 bufferbuff
. - encodeFloat(PositionedByteRange, float) - Method in class org.apache.hadoop.hbase.types.OrderedFloat32
-
Write instance
val
into bufferbuff
. - 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 bufferbuff
. - encodeInt(PositionedByteRange, int) - Method in class org.apache.hadoop.hbase.types.OrderedInt32
-
Write instance
val
into bufferdst
. - 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 bufferbuff
. - encodeLong(PositionedByteRange, long) - Method in class org.apache.hadoop.hbase.types.OrderedInt64
-
Write instance
val
into bufferdst
. - encodeLong(PositionedByteRange, long) - Method in class org.apache.hadoop.hbase.types.OrderedNumeric
-
Write instance
val
into bufferdst
. - 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
- encodeShort(byte[], int, short) - Method in class org.apache.hadoop.hbase.types.RawShort
-
Write instance
val
into bufferbuff
. - encodeShort(PositionedByteRange, short) - Method in class org.apache.hadoop.hbase.types.OrderedInt16
-
Write instance
val
into bufferdst
. - 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_KEY - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
- 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 class org.apache.hadoop.hbase.hbtop.terminal.KeyPress.Type
- END - Enum constant in enum class 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.PrefixKeyDeltaEncoder
- 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
- endKey - Variable in class org.apache.hadoop.hbase.util.LoadTestTool
- endKey - Variable in class org.apache.hadoop.hbase.util.MultiThreadedAction
-
The end key of the key range, exclusive
- 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.
- ensureExtendedCell(Cell) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
In fact, in HBase, all
Cell
s areExtendedCell
s. - ensureKeyValue(ExtendedCell) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
-
Deprecated.without any replacement.
- ensureKeyValues(List<ExtendedCell>) - 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
- ensureSomeNonStoppedRegionServersAvailable(int) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Make sure that at least the specified number of region servers are running.
- ensureSomeRegionServersAvailable(int) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Make sure that at least the specified number of region servers are running
- ensureSpace(ByteBuffer, int) - Static method in class org.apache.hadoop.hbase.io.encoding.PrefixKeyDeltaEncoder
-
Asserts that there is at least the given amount of unfilled space remaining in the given buffer.
- Enter - Enum constant in enum class 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.BoundedRecoveredHFilesOutputSink
- 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 class org.apache.hadoop.hbase.wal.WALTailingReader.State
- EOF_AND_RESET - Enum constant in enum class 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 class 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 class 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 class org.apache.hadoop.hbase.CompareOperator
-
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.Get
- 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.SlowLogParams
- equals(Object) - Method in class org.apache.hadoop.hbase.client.TableState
- 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.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.HRegionLocation
- 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.PerformanceEvaluation.RunResult
- 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.replication.ReplicationQueueId
- 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.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
- equals(ByteBuffer, int, int, ByteBuffer, int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
- 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
- equals(ExtendedCell, ExtendedCell) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
- equalsIgnoreMvccVersion(ExtendedCell, ExtendedCell) - 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
- Err(ServerName) - Constructor for class org.apache.hadoop.hbase.SplitLogTask.Err
-
Deprecated.
- ERR - Enum constant in enum class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination.TaskFinisher.Status
-
task completed with error
- ERR - Enum constant in enum class 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 class org.apache.hadoop.hbase.regionserver.wal.WALActionsListener.RollRequestReason
-
I/O or other error.
- ERROR - Enum constant in enum class org.apache.hadoop.hbase.security.SaslStatus
- ERROR - Enum constant in enum class org.apache.hadoop.hbase.tool.coprocessor.CoprocessorViolation.Severity
- ERROR_AND_RESET - Enum constant in enum class 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 class 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 class 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 [].
- 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.PrivateCellUtil
-
Estimate based on keyvalue's serialization format in the RPC layer.
- 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
- EvaluationMapTask() - Constructor for class org.apache.hadoop.hbase.PerformanceEvaluation.EvaluationMapTask
- 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.
- eventLoopGroupConfig - Variable in class org.apache.hadoop.hbase.HBaseServerBase
- 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_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.
- EVICT_BLOCKS_ON_SPLIT_KEY - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
- 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
- evictBlocksRangeByHfileName(String, long, long) - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCache
-
Evict all blocks for the given file name between the passed offset values.
- evictBlocksRangeByHfileName(String, long, long) - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
- 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.
- 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 class 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 heapByteBuff
now; at the same time, if allocate an off-heapByteBuff
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.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(RpcController, MasterProtos.ExecProcedureRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
Triggers an asynchronous attempt to run a distributed procedure.
- 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.
- 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(AdminProtos.ExecuteProceduresRequest) - Method in class org.apache.hadoop.hbase.client.AsyncRegionServerAdmin
- executeProcedures(RpcController, AdminProtos.ExecuteProceduresRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- 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.
- EXECUTOR_STATUS_COLLECT_ENABLED - Static variable in class org.apache.hadoop.hbase.HConstants
- executorService - Variable in class org.apache.hadoop.hbase.HBaseServerBase
- org.apache.hadoop.hbase.ExecutorStatusChore - Class in org.apache.hadoop.hbase
-
The Class ExecutorStatusChore for collect Executor status info periodically and report to metrics system
- ExecutorStatusChore(int, Stoppable, ExecutorService, MetricsRegionServerSource) - Constructor for class org.apache.hadoop.hbase.ExecutorStatusChore
- 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, long) - Method in class org.apache.hadoop.hbase.zookeeper.ReadOnlyZKClient
- 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 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 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.
- 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, String) - Static method in class org.apache.hadoop.hbase.util.OOMEChecker
- 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 class 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 class 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
- expireMasterSession() - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Expire the Master's session
- expireRegionServerSession(int) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Expire a region server's session
- expireServer(ServerName) - Method in class org.apache.hadoop.hbase.master.ServerManager
-
Expire the passed server.
- expireSession(ZKWatcher) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- expireSession(ZKWatcher, boolean) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Expire a ZooKeeper session as recommended in ZooKeeper documentation http://hbase.apache.org/book.html#trouble.zookeeper There are issues when doing this: [1] http://www.mail-archive.com/dev@zookeeper.apache.org/msg01942.html [2] https://issues.apache.org/jira/browse/ZOOKEEPER-1105
- explainTableAvailability(TableName) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- explainTableState(TableName, TableState.State) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- 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.ChecksumComparison - Enum Class in org.apache.hadoop.hbase.snapshot
-
Indicates the checksum comparison result.
- org.apache.hadoop.hbase.snapshot.ExportSnapshot.Counter - Enum Class 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.ExtendedCellScannable - Interface in org.apache.hadoop.hbase
-
We use this class in HBase internally for getting
ExtendedCell
directly without casting. - org.apache.hadoop.hbase.ExtendedCellScanner - Interface in org.apache.hadoop.hbase
-
We use this class in HBase internally for getting
ExtendedCell
directly without casting. - 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 likeboolean
, etc. - extendLimit(ByteBuffer, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
- 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 (the 'FileNum') 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
andTableName
from the providedResult
and adds them to the givenMap
. - 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 class org.apache.hadoop.hbase.hbtop.terminal.KeyPress.Type
- F10 - Enum constant in enum class org.apache.hadoop.hbase.hbtop.terminal.KeyPress.Type
- F11 - Enum constant in enum class org.apache.hadoop.hbase.hbtop.terminal.KeyPress.Type
- F12 - Enum constant in enum class org.apache.hadoop.hbase.hbtop.terminal.KeyPress.Type
- F2 - Enum constant in enum class org.apache.hadoop.hbase.hbtop.terminal.KeyPress.Type
- F3 - Enum constant in enum class org.apache.hadoop.hbase.hbtop.terminal.KeyPress.Type
- F4 - Enum constant in enum class org.apache.hadoop.hbase.hbtop.terminal.KeyPress.Type
- F5 - Enum constant in enum class org.apache.hadoop.hbase.hbtop.terminal.KeyPress.Type
- F6 - Enum constant in enum class org.apache.hadoop.hbase.hbtop.terminal.KeyPress.Type
- F7 - Enum constant in enum class org.apache.hadoop.hbase.hbtop.terminal.KeyPress.Type
- F8 - Enum constant in enum class org.apache.hadoop.hbase.hbtop.terminal.KeyPress.Type
- F9 - Enum constant in enum class org.apache.hadoop.hbase.hbtop.terminal.KeyPress.Type
- factory - Variable in class org.apache.hadoop.hbase.wal.AbstractWALProvider
- failed() - Method in class org.apache.hadoop.hbase.client.ClientCoprocessorRpcController
- failed() - Method in class org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
- failed() - Method in class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
- failed() - Method in class org.apache.hadoop.hbase.ipc.ServerRpcController
- FAILED - Enum constant in enum class org.apache.hadoop.hbase.backup.BackupInfo.BackupState
- FAILED_APPEND_KEY - Static variable in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
- FAILED_CLOSE - Enum constant in enum class org.apache.hadoop.hbase.master.RegionState.State
- FAILED_DELETE_KEY - Static variable in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
- FAILED_GET_KEY - Static variable in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
- FAILED_INCREMENT_KEY - Static variable in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
- FAILED_OPEN - Enum constant in enum class org.apache.hadoop.hbase.master.RegionState.State
- FAILED_PUT_KEY - Static variable in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
- FAILED_SCAN_KEY - Static variable in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
- FAILED_SERVER_EXPIRY_DEFAULT - Static variable in interface org.apache.hadoop.hbase.ipc.RpcClient
- FAILED_SERVER_EXPIRY_KEY - Static variable in interface org.apache.hadoop.hbase.ipc.RpcClient
- org.apache.hadoop.hbase.backup.FailedArchiveException - Exception in org.apache.hadoop.hbase.backup
-
Exception indicating that some files in the requested set could not be archived.
- FailedArchiveException(String, Collection<Path>) - Constructor for exception org.apache.hadoop.hbase.backup.FailedArchiveException
- failedBulkLoad(byte[], String) - Method in interface org.apache.hadoop.hbase.regionserver.HRegion.BulkLoadListener
-
Called after a failed HFile load
- failedFuture(Throwable) - Static method in class org.apache.hadoop.hbase.util.FutureUtils
-
Returns a CompletableFuture that is already completed exceptionally with the given exception.
- failedKeySet - Variable in class org.apache.hadoop.hbase.util.MultiThreadedWriterBase
-
The sorted set of keys NOT inserted/updated by the writers
- org.apache.hadoop.hbase.regionserver.wal.FailedLogCloseException - Exception in org.apache.hadoop.hbase.regionserver.wal
-
Thrown when we fail close of the write-ahead-log file.
- FailedLogCloseException() - Constructor for exception org.apache.hadoop.hbase.regionserver.wal.FailedLogCloseException
- FailedLogCloseException(String) - Constructor for exception org.apache.hadoop.hbase.regionserver.wal.FailedLogCloseException
- FailedLogCloseException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.regionserver.wal.FailedLogCloseException
- FailedLogCloseException(Throwable) - Constructor for exception org.apache.hadoop.hbase.regionserver.wal.FailedLogCloseException
- failedOnException() - Method in class org.apache.hadoop.hbase.ipc.ServerRpcController
-
Returns whether or not a server exception was generated in the prior RPC invocation.
- org.apache.hadoop.hbase.exceptions.FailedSanityCheckException - Exception in org.apache.hadoop.hbase.exceptions
-
Exception thrown if a mutation fails sanity checks.
- FailedSanityCheckException() - Constructor for exception org.apache.hadoop.hbase.exceptions.FailedSanityCheckException
-
default constructor
- FailedSanityCheckException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.FailedSanityCheckException
- FailedSanityCheckException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.exceptions.FailedSanityCheckException
- failedSanityException() - Method in interface org.apache.hadoop.hbase.metrics.ExceptionTrackingSource
- failedSanityException() - Method in class org.apache.hadoop.hbase.metrics.ExceptionTrackingSourceImpl
- org.apache.hadoop.hbase.ipc.FailedServerException - Exception in org.apache.hadoop.hbase.ipc
-
Indicates that we're trying to connect to a already known as dead server.
- FailedServerException(String) - Constructor for exception org.apache.hadoop.hbase.ipc.FailedServerException
- failedServers - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
- org.apache.hadoop.hbase.ipc.FailedServers - Class in org.apache.hadoop.hbase.ipc
-
A class to manage a list of servers that failed recently.
- FailedServers(Configuration) - Constructor for class org.apache.hadoop.hbase.ipc.FailedServers
- org.apache.hadoop.hbase.regionserver.wal.FailedSyncBeforeLogCloseException - Exception in org.apache.hadoop.hbase.regionserver.wal
-
Thrown when we fail close of the write-ahead-log file.
- FailedSyncBeforeLogCloseException() - Constructor for exception org.apache.hadoop.hbase.regionserver.wal.FailedSyncBeforeLogCloseException
- FailedSyncBeforeLogCloseException(String) - Constructor for exception org.apache.hadoop.hbase.regionserver.wal.FailedSyncBeforeLogCloseException
- FailedSyncBeforeLogCloseException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.regionserver.wal.FailedSyncBeforeLogCloseException
- FailedSyncBeforeLogCloseException(Throwable) - Constructor for exception org.apache.hadoop.hbase.regionserver.wal.FailedSyncBeforeLogCloseException
- failedToWriteKey(long) - Method in class org.apache.hadoop.hbase.util.MultiThreadedWriterBase
- failInsert() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
- failOnHashAlgorithmMismatch(Configuration) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
-
Returns the Hash Algorithm mismatch behaviour defined in the crypto configuration.
- FAILURE - Enum constant in enum class org.apache.hadoop.hbase.HConstants.OperationStatusCode
- FAILURE - Enum constant in enum class org.apache.hadoop.hbase.master.SplitLogManager.TerminationStatus
-
Deprecated.
- FAILURE - Static variable in class org.apache.hadoop.hbase.regionserver.OperationStatus
-
Singleton for failed operations.
- failureCause() - Method in interface org.apache.hadoop.hbase.replication.ReplicationEndpoint
-
Returns the
Throwable
that caused this service to fail. - failureSleep - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
- FAIR_REENTRANT_CLOSE_LOCK - Static variable in class org.apache.hadoop.hbase.regionserver.HRegion
-
Conf key for fair locking policy
- FALLBACK_GROUP_ENABLE_KEY - Static variable in class org.apache.hadoop.hbase.rsgroup.RSGroupBasedLoadBalancer
-
Set this key to
true
to allow region fallback. - FALLBACK_TO_INSECURE_CLIENT_AUTH - Static variable in class org.apache.hadoop.hbase.ipc.RpcServer
-
Whether we allow a fallback to SIMPLE auth for insecure clients when security is enabled.
- fallbackAllowed - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
- fallbackAllowed - Variable in class org.apache.hadoop.hbase.security.AbstractHBaseSaslRpcClient
- org.apache.hadoop.hbase.ipc.FallbackDisallowedException - Exception in org.apache.hadoop.hbase.ipc
-
Indicate that the rpc server tells client to fallback to simple auth but client is disabled to do so.
- FallbackDisallowedException() - Constructor for exception org.apache.hadoop.hbase.ipc.FallbackDisallowedException
- fallbackToFsChecksum(int) - Method in class org.apache.hadoop.hbase.io.FSDataInputStreamWrapper
-
Read from non-checksum stream failed, fall back to FS checksum.
- FALSE - Enum constant in enum class org.apache.hadoop.hbase.KeepDeletedCells
-
Deleted Cells are not retained.
- FALSE - Enum constant in enum class org.apache.hadoop.hbase.snapshot.ExportSnapshot.ChecksumComparison
- fam1 - Static variable in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- fam2 - Static variable in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- fam3 - Static variable in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- family - Variable in class org.apache.hadoop.hbase.ExtendedCellBuilderImpl
- FAMILY - Enum constant in enum class org.apache.hadoop.hbase.regionserver.wal.CompressionContext.DictionaryIndex
- FAMILY_DELETED - Enum constant in enum class org.apache.hadoop.hbase.regionserver.querymatcher.DeleteTracker.DeleteResult
- FAMILY_KEY_STR - Static variable in class org.apache.hadoop.hbase.HConstants
-
The family str as a key in map
- FAMILY_LENGTH_SIZE - Static variable in class org.apache.hadoop.hbase.KeyValue
-
Size of the family length field in bytes
- FAMILY_NAME_BASE - Static variable in class org.apache.hadoop.hbase.PerformanceEvaluation
- FAMILY_VERSION_DELETED - Enum constant in enum class org.apache.hadoop.hbase.regionserver.querymatcher.DeleteTracker.DeleteResult
- FAMILY_ZERO - Static variable in class org.apache.hadoop.hbase.PerformanceEvaluation
- FamilyDirFilter(FileSystem) - Constructor for class org.apache.hadoop.hbase.util.FSUtils.FamilyDirFilter
- org.apache.hadoop.hbase.filter.FamilyFilter - Class in org.apache.hadoop.hbase.filter
-
This filter is used to filter based on the column family.
- FamilyFilter(CompareOperator, ByteArrayComparable) - Constructor for class org.apache.hadoop.hbase.filter.FamilyFilter
-
Constructor.
- familyHasReferenceFile(HRegionFileSystem, String, long) - Method in class org.apache.hadoop.hbase.util.compaction.MajorCompactionTTLRequest
- familyMap - Variable in class org.apache.hadoop.hbase.client.Mutation
- familySet() - Method in class org.apache.hadoop.hbase.client.Get
-
Method for retrieving the keys in the familyMap
- familyStamp - Variable in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanDeleteTracker
- familyVersionStamps - Variable in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanDeleteTracker
- org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutput - Class in org.apache.hadoop.hbase.io.asyncfs
-
An asynchronous HDFS output stream implementation which fans out data to datanode and only supports writing file with only one block.
- org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputHelper - Class in org.apache.hadoop.hbase.io.asyncfs
-
Helper class for implementing
FanOutOneBlockAsyncDFSOutput
. - org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputHelper.NameNodeException - Exception in org.apache.hadoop.hbase.io.asyncfs
-
Exception other than RemoteException thrown when calling create on namenode
- org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputSaslHelper - Class in org.apache.hadoop.hbase.io.asyncfs
-
Helper class for adding sasl support for
FanOutOneBlockAsyncDFSOutput
. - FAST_DIFF - Enum constant in enum class org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
- org.apache.hadoop.hbase.io.encoding.FastDiffDeltaEncoder - Class in org.apache.hadoop.hbase.io.encoding
-
Encoder similar to
DiffKeyDeltaEncoder
but supposedly faster. - FastDiffDeltaEncoder() - Constructor for class org.apache.hadoop.hbase.io.encoding.FastDiffDeltaEncoder
- org.apache.hadoop.hbase.io.encoding.FastDiffDeltaEncoder.FastDiffSeekerState - Class in org.apache.hadoop.hbase.io.encoding
- FastDiffSeekerState(ObjectIntPair<ByteBuffer>, boolean) - Constructor for class org.apache.hadoop.hbase.io.encoding.FastDiffDeltaEncoder.FastDiffSeekerState
- org.apache.hadoop.hbase.ipc.FastPathBalancedQueueRpcExecutor - Class in org.apache.hadoop.hbase.ipc
-
Balanced queue executor with a fastpath.
- FastPathBalancedQueueRpcExecutor(String, int, int, PriorityFunction, Configuration, Abortable) - Constructor for class org.apache.hadoop.hbase.ipc.FastPathBalancedQueueRpcExecutor
- FastPathBalancedQueueRpcExecutor(String, int, String, int, PriorityFunction, Configuration, Abortable) - Constructor for class org.apache.hadoop.hbase.ipc.FastPathBalancedQueueRpcExecutor
- org.apache.hadoop.hbase.ipc.FastPathRpcHandler - Class in org.apache.hadoop.hbase.ipc
- org.apache.hadoop.hbase.ipc.FastPathRWQueueRpcExecutor - Class in org.apache.hadoop.hbase.ipc
-
RPC Executor that extends
RWQueueRpcExecutor
with fast-path feature, used inFastPathBalancedQueueRpcExecutor
. - FastPathRWQueueRpcExecutor(String, int, int, PriorityFunction, Configuration, Abortable) - Constructor for class org.apache.hadoop.hbase.ipc.FastPathRWQueueRpcExecutor
- FATAL - Static variable in class org.apache.hadoop.hbase.log.HBaseMarkers
- org.apache.hadoop.hbase.ipc.FatalConnectionException - Exception in org.apache.hadoop.hbase.ipc
-
Thrown when server finds fatal issue w/ connection setup: e.g.
- FatalConnectionException() - Constructor for exception org.apache.hadoop.hbase.ipc.FatalConnectionException
- FatalConnectionException(String) - Constructor for exception org.apache.hadoop.hbase.ipc.FatalConnectionException
- FatalConnectionException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.ipc.FatalConnectionException
- FAVORED_ALWAYS_ASSIGN_REGIONS - Static variable in interface org.apache.hadoop.hbase.favored.FavoredNodesPromoter
- FAVORED_NODES_NUM - Static variable in class org.apache.hadoop.hbase.favored.FavoredNodeAssignmentHelper
- org.apache.hadoop.hbase.favored.FavoredNodeAssignmentHelper - Class in org.apache.hadoop.hbase.favored
-
Helper class for FavoredNodeLoadBalancer that has all the intelligence for racks, meta scans, etc.
- FavoredNodeAssignmentHelper(List<ServerName>, Configuration) - Constructor for class org.apache.hadoop.hbase.favored.FavoredNodeAssignmentHelper
- FavoredNodeAssignmentHelper(List<ServerName>, RackManager) - Constructor for class org.apache.hadoop.hbase.favored.FavoredNodeAssignmentHelper
- org.apache.hadoop.hbase.favored.FavoredNodeLoadBalancer - Class in org.apache.hadoop.hbase.favored
-
An implementation of the
LoadBalancer
that assigns favored nodes for each region. - FavoredNodeLoadBalancer() - Constructor for class org.apache.hadoop.hbase.favored.FavoredNodeLoadBalancer
- favoredNodes - Variable in class org.apache.hadoop.hbase.io.hfile.HFile.WriterFactory
- FAVOREDNODES_QUALIFIER - Static variable in class org.apache.hadoop.hbase.favored.FavoredNodeAssignmentHelper
- org.apache.hadoop.hbase.regionserver.FavoredNodesForRegion - Interface in org.apache.hadoop.hbase.regionserver
-
Abstraction that allows different modules in RegionServer to update/get the favored nodes information for regions.
- org.apache.hadoop.hbase.favored.FavoredNodesManager - Class in org.apache.hadoop.hbase.favored
-
FavoredNodesManager is responsible for maintaining favored nodes info in internal cache and META table.
- FavoredNodesManager(ClusterInfoProvider) - Constructor for class org.apache.hadoop.hbase.favored.FavoredNodesManager
- org.apache.hadoop.hbase.favored.FavoredNodesPlan - Class in org.apache.hadoop.hbase.favored
-
This class contains the mapping information between each region name and its favored region server list.
- FavoredNodesPlan() - Constructor for class org.apache.hadoop.hbase.favored.FavoredNodesPlan
- org.apache.hadoop.hbase.favored.FavoredNodesPlan.Position - Enum Class in org.apache.hadoop.hbase.favored
- org.apache.hadoop.hbase.favored.FavoredNodesPromoter - Interface in org.apache.hadoop.hbase.favored
- fetchEndpoints() - Method in class org.apache.hadoop.hbase.client.MasterRegistry
-
Deprecated.
- fetchEndpoints() - Method in class org.apache.hadoop.hbase.client.RpcConnectionRegistry
- fetchGlobalQuotas(String, Connection, List<Get>, QuotaUtil.KeyFromRow<K>) - Static method in class org.apache.hadoop.hbase.quotas.QuotaUtil
- fetchNamespaceQuotas(Connection, List<Get>, double) - Static method in class org.apache.hadoop.hbase.quotas.QuotaUtil
- fetchPeerAddresses() - Method in class org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint
-
Get the list of all the region servers from the specified peer
- fetchRegionServerQuotas(Connection, List<Get>) - Static method in class org.apache.hadoop.hbase.quotas.QuotaUtil
- fetchSnapshotsFromQuotaTable() - Method in class org.apache.hadoop.hbase.quotas.SpaceQuotaRefresherChore
-
Reads all quota snapshots from the quota table.
- fetchTableQuotas(Connection, List<Get>, Map<TableName, Double>) - Static method in class org.apache.hadoop.hbase.quotas.QuotaUtil
- fetchUserQuotas(Connection, List<Get>, Map<TableName, Double>, double) - Static method in class org.apache.hadoop.hbase.quotas.QuotaUtil
- org.apache.hadoop.hbase.hbtop.field.Field - Enum Class in org.apache.hadoop.hbase.hbtop.field
-
Represents fields that are displayed in the top screen.
- org.apache.hadoop.hbase.hbtop.field.FieldInfo - Class in org.apache.hadoop.hbase.hbtop.field
-
Information about a field.
- FieldInfo(Field, int, boolean) - Constructor for class org.apache.hadoop.hbase.hbtop.field.FieldInfo
- fields - Variable in class org.apache.hadoop.hbase.types.Struct
- fields - Variable in class org.apache.hadoop.hbase.types.StructBuilder
- org.apache.hadoop.hbase.hbtop.screen.field.FieldScreenPresenter - Class in org.apache.hadoop.hbase.hbtop.screen.field
-
The presentation logic for the field screen.
- FieldScreenPresenter(FieldScreenView, Field, List<Field>, EnumMap<Field, Boolean>, FieldScreenPresenter.ResultListener, ScreenView) - Constructor for class org.apache.hadoop.hbase.hbtop.screen.field.FieldScreenPresenter
- org.apache.hadoop.hbase.hbtop.screen.field.FieldScreenPresenter.ResultListener - Interface in org.apache.hadoop.hbase.hbtop.screen.field
- org.apache.hadoop.hbase.hbtop.screen.field.FieldScreenView - Class in org.apache.hadoop.hbase.hbtop.screen.field
-
The screen where we can change the displayed fields, the sort key and the order of the fields.
- FieldScreenView(Screen, Terminal, Field, List<Field>, EnumMap<Field, Boolean>, FieldScreenPresenter.ResultListener, ScreenView) - Constructor for class org.apache.hadoop.hbase.hbtop.screen.field.FieldScreenView
- org.apache.hadoop.hbase.hbtop.field.FieldValue - Class in org.apache.hadoop.hbase.hbtop.field
-
Represents a value of a field.
- org.apache.hadoop.hbase.hbtop.field.FieldValueType - Enum Class in org.apache.hadoop.hbase.hbtop.field
-
Represents the type of a
FieldValue
. - org.apache.hadoop.hbase.ipc.FifoRpcScheduler - Class in org.apache.hadoop.hbase.ipc
-
A very simple RpcScheduler} that serves incoming requests in order.
- FifoRpcScheduler(Configuration, int) - Constructor for class org.apache.hadoop.hbase.ipc.FifoRpcScheduler
- org.apache.hadoop.hbase.regionserver.FifoRpcSchedulerFactory - Class in org.apache.hadoop.hbase.regionserver
-
Factory to use when you want to use the
FifoRpcScheduler
- FifoRpcSchedulerFactory() - Constructor for class org.apache.hadoop.hbase.regionserver.FifoRpcSchedulerFactory
- FILE - Enum constant in enum class org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileTrackerFactory.Trackers
- FILE_INFO - Enum constant in enum class org.apache.hadoop.hbase.io.hfile.BlockType
-
File info, version 2
- FILE_SYSTEM_UTILIZATION_CHORE_TIME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerQuotaSource
- FILE_SYSTEM_VERSION - Static variable in class org.apache.hadoop.hbase.HConstants
-
Current version of file system.
- org.apache.hadoop.hbase.quotas.FileArchiverNotifier - Interface in org.apache.hadoop.hbase.quotas
-
Interface allowing various implementations of tracking files that have recently been archived to allow for the Master to notice changes to snapshot sizes for space quotas.
- org.apache.hadoop.hbase.quotas.FileArchiverNotifierFactory - Interface in org.apache.hadoop.hbase.quotas
-
Factory class to create
FileArchiverNotifier
instances. - org.apache.hadoop.hbase.quotas.FileArchiverNotifierFactoryImpl - Class in org.apache.hadoop.hbase.quotas
-
A factory for getting instances of
FileArchiverNotifier
. - org.apache.hadoop.hbase.quotas.FileArchiverNotifierImpl - Class in org.apache.hadoop.hbase.quotas
-
Tracks file archiving and updates the hbase quota table.
- FileArchiverNotifierImpl(Connection, Configuration, FileSystem, TableName) - Constructor for class org.apache.hadoop.hbase.quotas.FileArchiverNotifierImpl
- org.apache.hadoop.hbase.quotas.FileArchiverNotifierImpl.QuotaSnapshotSizeSerializationException - Exception in org.apache.hadoop.hbase.quotas
-
An Exception thrown when SnapshotSize updates to hbase:quota fail to be written.
- org.apache.hadoop.hbase.io.FileChangeWatcher - Class in org.apache.hadoop.hbase.io
-
Instances of this class can be used to watch a directory for file changes.
- FileChangeWatcher(Path, String, Consumer<WatchEvent<?>>) - Constructor for class org.apache.hadoop.hbase.io.FileChangeWatcher
-
Creates a watcher that watches
dirPath
and invokescallback
on changes. - org.apache.hadoop.hbase.io.FileChangeWatcher.State - Enum Class in org.apache.hadoop.hbase.io
- fileInfo - Variable in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
- fileInfo - Variable in class org.apache.hadoop.hbase.io.hfile.HFileWriterImpl
-
A "file info" block: a key-value map of file-wide metadata.
- fileLength - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractProtobufWALReader
- org.apache.hadoop.hbase.io.FileLink - Class in org.apache.hadoop.hbase.io
-
The FileLink is a sort of hardlink, that allows access to a file given a set of locations.
- FileLink() - Constructor for class org.apache.hadoop.hbase.io.FileLink
- FileLink(Collection<Path>) - Constructor for class org.apache.hadoop.hbase.io.FileLink
- FileLink(Path, Path...) - Constructor for class org.apache.hadoop.hbase.io.FileLink
- org.apache.hadoop.hbase.io.FileLink.FileLinkInputStream - Class in org.apache.hadoop.hbase.io
-
FileLink InputStream that handles the switch between the original path and the alternative locations, when the file is moved.
- FileLinkInputStream(FileSystem, FileLink) - Constructor for class org.apache.hadoop.hbase.io.FileLink.FileLinkInputStream
- FileLinkInputStream(FileSystem, FileLink, int) - Constructor for class org.apache.hadoop.hbase.io.FileLink.FileLinkInputStream
- filename(String) - Method in class org.apache.hadoop.hbase.util.RegionMover.RegionMoverBuilder
-
Path of file where regions will be written to during unloading/read from during loading
- filenum - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
- FILES_COPIED - Enum constant in enum class org.apache.hadoop.hbase.snapshot.ExportSnapshot.Counter
- FILES_SKIPPED - Enum constant in enum class org.apache.hadoop.hbase.snapshot.ExportSnapshot.Counter
- org.apache.hadoop.hbase.util.FileStatusFilter - Interface in org.apache.hadoop.hbase.util
- fileStoragePolicy() - Method in class org.apache.hadoop.hbase.regionserver.CreateStoreFileWriterParams
- fileStoragePolicy(String) - Method in class org.apache.hadoop.hbase.regionserver.CreateStoreFileWriterParams
- FILESYSTEM - Enum constant in enum class org.apache.hadoop.hbase.replication.ReplicationPeerStorageType
- org.apache.hadoop.hbase.quotas.FileSystemUtilizationChore - Class in org.apache.hadoop.hbase.quotas
-
A chore which computes the size of each
HRegion
on the FileSystem hosted by the givenHRegionServer
. - FileSystemUtilizationChore(HRegionServer) - Constructor for class org.apache.hadoop.hbase.quotas.FileSystemUtilizationChore
- org.apache.hadoop.hbase.util.FileSystemVersionException - Exception in org.apache.hadoop.hbase.util
-
Thrown when the file system needs to be upgraded
- FileSystemVersionException() - Constructor for exception org.apache.hadoop.hbase.util.FileSystemVersionException
-
default constructor
- FileSystemVersionException(String) - Constructor for exception org.apache.hadoop.hbase.util.FileSystemVersionException
- FILL_HEADER - Static variable in class org.apache.hadoop.hbase.io.hfile.HFileBlock
- fillFamilyRange(Cell, ByteRange) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
- fillQualifierRange(Cell, ByteRange) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
- fillRegion(HRegion) - Method in interface org.apache.hadoop.hbase.util.ModifyRegionUtils.RegionFillTask
- fillRowRange(Cell, ByteRange) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
ByteRange
- fillTables(RSGroupInfo, Collection<TableDescriptor>) - Static method in class org.apache.hadoop.hbase.rsgroup.RSGroupUtil
-
Fill the tables field for
RSGroupInfo
, for backward compatibility. - fillTagRange(ExtendedCell, ByteRange) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
- fillUp(TableName, SnapshotOfRegionAssignmentFromMeta, Map<String, Map<String, Float>>) - Method in class org.apache.hadoop.hbase.master.AssignmentVerificationReport
- fillUpDispersion(TableName, SnapshotOfRegionAssignmentFromMeta, FavoredNodesPlan) - Method in class org.apache.hadoop.hbase.master.AssignmentVerificationReport
-
Use this to project the dispersion scores
- fillValueRange(Cell, ByteRange) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
- filter - Variable in class org.apache.hadoop.hbase.client.Query
- filter - Variable in class org.apache.hadoop.hbase.regionserver.querymatcher.UserScanQueryMatcher
- filter(WAL.Entry) - Method in class org.apache.hadoop.hbase.replication.ChainWALEmptyEntryFilter
- filter(WAL.Entry) - Method in class org.apache.hadoop.hbase.replication.ChainWALEntryFilter
- filter(WAL.Entry) - Method in class org.apache.hadoop.hbase.replication.ClusterMarkingEntryFilter
- filter(WAL.Entry) - Method in class org.apache.hadoop.hbase.replication.NamespaceTableCfWALEntryFilter
- filter(WAL.Entry) - Method in class org.apache.hadoop.hbase.replication.ScopeWALEntryFilter
- filter(WAL.Entry) - Method in class org.apache.hadoop.hbase.replication.SystemTableWALEntryFilter
- filter(WAL.Entry) - Method in interface org.apache.hadoop.hbase.replication.WALEntryFilter
-
Applies the filter, possibly returning a different Entry instance.
- filter(Mapper.Context, Cell) - Method in class org.apache.hadoop.hbase.mapreduce.WALPlayer.WALMapper
- filter(ContainerRequestContext, ContainerResponseContext) - Method in class org.apache.hadoop.hbase.http.jersey.ResponseEntityMapper
- org.apache.hadoop.hbase.filter.Filter - Class in org.apache.hadoop.hbase.filter
-
Interface for row and column filters directly applied within the regionserver.
- Filter() - Constructor for class org.apache.hadoop.hbase.filter.Filter
- FILTER - Static variable in interface org.apache.hadoop.hbase.rest.Constants
- FILTER_ARGS_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.Import
- FILTER_B64 - Static variable in interface org.apache.hadoop.hbase.rest.Constants
- FILTER_CLASS_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.Import
- FILTER_CLASSES - Static variable in interface org.apache.hadoop.hbase.rest.Constants
- FILTER_PACKAGE - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
Package containing filters
- org.apache.hadoop.hbase.filter.Filter.ReturnCode - Enum Class in org.apache.hadoop.hbase.filter
-
Return codes for filterValue().
- org.apache.hadoop.hbase.filter.FilterAllFilter - Class in org.apache.hadoop.hbase.filter
- FilterAllFilter() - Constructor for class org.apache.hadoop.hbase.filter.FilterAllFilter
- filterAllRemaining() - Method in class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
- filterAllRemaining() - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
- filterAllRemaining() - Method in class org.apache.hadoop.hbase.filter.Filter
-
If this returns true, the scan will terminate.
- filterAllRemaining() - Method in class org.apache.hadoop.hbase.filter.FilterBase
-
Filters that never filter all remaining can inherit this implementation that never stops the filter early.
- filterAllRemaining() - Method in class org.apache.hadoop.hbase.filter.FilterList
- filterAllRemaining() - Method in class org.apache.hadoop.hbase.filter.FilterListWithAND
- filterAllRemaining() - Method in class org.apache.hadoop.hbase.filter.FilterListWithOR
- filterAllRemaining() - Method in class org.apache.hadoop.hbase.filter.FilterWrapper
- filterAllRemaining() - Method in class org.apache.hadoop.hbase.filter.FuzzyRowFilter
- filterAllRemaining() - Method in class org.apache.hadoop.hbase.filter.InclusiveStopFilter
- filterAllRemaining() - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter
- filterAllRemaining() - Method in class org.apache.hadoop.hbase.filter.PageFilter
- filterAllRemaining() - Method in class org.apache.hadoop.hbase.filter.PrefixFilter
- filterAllRemaining() - Method in class org.apache.hadoop.hbase.filter.RandomRowFilter
- filterAllRemaining() - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
- org.apache.hadoop.hbase.filter.FilterBase - Class in org.apache.hadoop.hbase.filter
-
Abstract base class to help you implement new Filters.
- FilterBase() - Constructor for class org.apache.hadoop.hbase.filter.FilterBase
- filterBySubject(String) - Method in class org.apache.hadoop.hbase.quotas.NamespaceQuotaSnapshotStore
- filterBySubject(TableName) - Method in class org.apache.hadoop.hbase.quotas.TableQuotaSnapshotStore
- filterBySubject(T) - Method in interface org.apache.hadoop.hbase.quotas.QuotaSnapshotStore
-
Filters the provided
regions
, returning those which match the givensubject
. - filterCell(Cell) - Method in class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
- filterCell(Cell) - Method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
- filterCell(Cell) - Method in class org.apache.hadoop.hbase.filter.ColumnPrefixFilter
- filterCell(Cell) - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
- filterCell(Cell) - Method in class org.apache.hadoop.hbase.filter.ColumnValueFilter
- filterCell(Cell) - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
- filterCell(Cell) - Method in class org.apache.hadoop.hbase.filter.FamilyFilter
- filterCell(Cell) - Method in class org.apache.hadoop.hbase.filter.Filter
-
A way to filter based on the column family, column qualifier and/or the column value.
- filterCell(Cell) - Method in class org.apache.hadoop.hbase.filter.FilterAllFilter
- filterCell(Cell) - Method in class org.apache.hadoop.hbase.filter.FilterList
- filterCell(Cell) - Method in class org.apache.hadoop.hbase.filter.FilterListWithAND
- filterCell(Cell) - Method in class org.apache.hadoop.hbase.filter.FilterListWithOR
- filterCell(Cell) - Method in class org.apache.hadoop.hbase.filter.FilterWrapper
- filterCell(Cell) - Method in class org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
- filterCell(Cell) - Method in class org.apache.hadoop.hbase.filter.FuzzyRowFilter
- filterCell(Cell) - Method in class org.apache.hadoop.hbase.filter.InclusiveStopFilter
- filterCell(Cell) - Method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter
- filterCell(Cell) - Method in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
- filterCell(Cell) - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter
- filterCell(Cell) - Method in class org.apache.hadoop.hbase.filter.PageFilter
- filterCell(Cell) - Method in class org.apache.hadoop.hbase.filter.PrefixFilter
- filterCell(Cell) - Method in class org.apache.hadoop.hbase.filter.QualifierFilter
- filterCell(Cell) - Method in class org.apache.hadoop.hbase.filter.RandomRowFilter
- filterCell(Cell) - Method in class org.apache.hadoop.hbase.filter.RowFilter
- filterCell(Cell) - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
- filterCell(Cell) - Method in class org.apache.hadoop.hbase.filter.SkipFilter
- filterCell(Cell) - Method in class org.apache.hadoop.hbase.filter.TimestampsFilter
- filterCell(Cell) - Method in class org.apache.hadoop.hbase.filter.ValueFilter
- filterCell(Cell) - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
- filterCell(ExtendedCell, Predicate<byte[]>) - Method in class org.apache.hadoop.hbase.replication.BulkLoadCellFilter
-
Filters the bulk load cell using the supplied predicate.
- filterCell(WAL.Entry, Cell) - Method in class org.apache.hadoop.hbase.replication.NamespaceTableCfWALEntryFilter
- filterCell(WAL.Entry, Cell) - Method in class org.apache.hadoop.hbase.replication.ScopeWALEntryFilter
- filterCell(WAL.Entry, Cell) - Method in interface org.apache.hadoop.hbase.replication.WALCellFilter
-
Applies the filter, possibly returning a different Cell instance.
- filterCells(WAL.Entry) - Method in class org.apache.hadoop.hbase.replication.ChainWALEntryFilter
- filterCells(WALEdit, Function<Cell, Cell>) - Static method in class org.apache.hadoop.hbase.regionserver.wal.WALUtil
- filterColumn(Cell) - Method in class org.apache.hadoop.hbase.filter.ColumnPrefixFilter
- filterColumn(Cell) - Method in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
- org.apache.hadoop.hbase.http.FilterContainer - Interface in org.apache.hadoop.hbase.http
-
A container interface to add javax.servlet.Filter.
- org.apache.hadoop.hbase.hbtop.screen.top.FilterDisplayModeScreenPresenter - Class in org.apache.hadoop.hbase.hbtop.screen.top
-
The presentation logic for the filter display mode.
- FilterDisplayModeScreenPresenter(FilterDisplayModeScreenView, List<RecordFilter>, ScreenView) - Constructor for class org.apache.hadoop.hbase.hbtop.screen.top.FilterDisplayModeScreenPresenter
- org.apache.hadoop.hbase.hbtop.screen.top.FilterDisplayModeScreenView - Class in org.apache.hadoop.hbase.hbtop.screen.top
-
The filter display mode in the top screen.
- FilterDisplayModeScreenView(Screen, Terminal, int, List<RecordFilter>, ScreenView) - Constructor for class org.apache.hadoop.hbase.hbtop.screen.top.FilterDisplayModeScreenView
- FILTERED_READ_REQUEST_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- FILTERED_READ_REQUEST_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- FILTERED_READ_REQUEST_COUNT_PER_SECOND - Enum constant in enum class org.apache.hadoop.hbase.hbtop.field.Field
- filterEntry(WAL.Entry) - Method in class org.apache.hadoop.hbase.replication.ChainWALEntryFilter
- filterFileStatuses(Iterator<FileStatus>, FileStatusFilter) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Filters FileStatuses in an iterator and returns a list
- filterFileStatuses(FileStatus[], FileStatusFilter) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Filters FileStatuses in an array and returns a list
- filterIfMissing - Variable in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
- org.apache.hadoop.hbase.http.FilterInitializer - Class in org.apache.hadoop.hbase.http
-
Initialize a javax.servlet.Filter.
- FilterInitializer() - Constructor for class org.apache.hadoop.hbase.http.FilterInitializer
- filterKv(Filter, ExtendedCell) - Static method in class org.apache.hadoop.hbase.mapreduce.Import
-
Attempt to filter out the keyvalue
- org.apache.hadoop.hbase.filter.FilterList - Class in org.apache.hadoop.hbase.filter
-
Implementation of
Filter
that represents an ordered List of Filters which will be evaluated with a specified boolean operatorFilterList.Operator.MUST_PASS_ALL
(AND
) orFilterList.Operator.MUST_PASS_ONE
(OR
). - FilterList(List<Filter>) - Constructor for class org.apache.hadoop.hbase.filter.FilterList
-
Constructor that takes a set of
Filter
s. - FilterList(Filter...) - Constructor for class org.apache.hadoop.hbase.filter.FilterList
-
Constructor that takes a var arg number of
Filter
s. - FilterList(FilterList.Operator) - Constructor for class org.apache.hadoop.hbase.filter.FilterList
-
Constructor that takes an operator.
- FilterList(FilterList.Operator, List<Filter>) - Constructor for class org.apache.hadoop.hbase.filter.FilterList
-
Constructor that takes a set of
Filter
s and an operator. - FilterList(FilterList.Operator, Filter...) - Constructor for class org.apache.hadoop.hbase.filter.FilterList
-
Constructor that takes a var arg number of
Filter
s and an operator. - org.apache.hadoop.hbase.filter.FilterList.Operator - Enum Class in org.apache.hadoop.hbase.filter
-
set operator
- org.apache.hadoop.hbase.filter.FilterListBase - Class in org.apache.hadoop.hbase.filter
-
Base class for FilterList.
- FilterListBase(List<Filter>) - Constructor for class org.apache.hadoop.hbase.filter.FilterListBase
- org.apache.hadoop.hbase.filter.FilterListWithAND - Class in org.apache.hadoop.hbase.filter
-
FilterListWithAND represents an ordered list of filters which will be evaluated with an AND operator.
- FilterListWithAND(List<Filter>) - Constructor for class org.apache.hadoop.hbase.filter.FilterListWithAND
- org.apache.hadoop.hbase.filter.FilterListWithOR - Class in org.apache.hadoop.hbase.filter
-
FilterListWithOR represents an ordered list of filters which will be evaluated with an OR operator.
- FilterListWithOR(List<Filter>) - Constructor for class org.apache.hadoop.hbase.filter.FilterListWithOR
- filterNames - Variable in class org.apache.hadoop.hbase.http.HttpServer
- filterNonFNApplicableRegions(Collection<RegionInfo>) - Static method in class org.apache.hadoop.hbase.favored.FavoredNodesManager
-
Filter and return regions for which favored nodes is not applicable.
- filterOutRow - Variable in class org.apache.hadoop.hbase.filter.RandomRowFilter
- filterRow - Variable in class org.apache.hadoop.hbase.filter.PrefixFilter
- filterRow() - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
- filterRow() - Method in class org.apache.hadoop.hbase.filter.Filter
-
Last chance to veto row based on previous
Filter.filterCell(Cell)
calls. - filterRow() - Method in class org.apache.hadoop.hbase.filter.FilterAllFilter
- filterRow() - Method in class org.apache.hadoop.hbase.filter.FilterBase
-
Filters that never filter by rows based on previously gathered state from
Filter.filterCell(Cell)
can inherit this implementation that never filters a row. - filterRow() - Method in class org.apache.hadoop.hbase.filter.FilterList
- filterRow() - Method in class org.apache.hadoop.hbase.filter.FilterListWithAND
- filterRow() - Method in class org.apache.hadoop.hbase.filter.FilterListWithOR
- filterRow() - Method in class org.apache.hadoop.hbase.filter.FilterWrapper
- filterRow() - Method in class org.apache.hadoop.hbase.filter.FuzzyRowFilter
- filterRow() - Method in class org.apache.hadoop.hbase.filter.PageFilter
- filterRow() - Method in class org.apache.hadoop.hbase.filter.PrefixFilter
- filterRow() - Method in class org.apache.hadoop.hbase.filter.RandomRowFilter
- filterRow() - Method in class org.apache.hadoop.hbase.filter.RowFilter
- filterRow() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
- filterRow() - Method in class org.apache.hadoop.hbase.filter.SkipFilter
- filterRow() - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
- filterRowCells(List<Cell>) - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
- filterRowCells(List<Cell>) - Method in class org.apache.hadoop.hbase.filter.Filter
-
Chance to alter the list of Cells to be submitted.
- filterRowCells(List<Cell>) - Method in class org.apache.hadoop.hbase.filter.FilterBase
-
Filters that never filter by modifying the returned List of Cells can inherit this implementation that does nothing.
- filterRowCells(List<Cell>) - Method in class org.apache.hadoop.hbase.filter.FilterList
-
Filters that never filter by modifying the returned List of Cells can inherit this implementation that does nothing.
- filterRowCells(List<Cell>) - Method in class org.apache.hadoop.hbase.filter.FilterListBase
-
Filters that never filter by modifying the returned List of Cells can inherit this implementation that does nothing.
- filterRowCells(List<Cell>) - Method in class org.apache.hadoop.hbase.filter.FilterWrapper
- filterRowCells(List<Cell>) - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter
- filterRowCellsWithRet(List<Cell>) - Method in class org.apache.hadoop.hbase.filter.FilterWrapper
- filterRowKey(Cell) - Method in class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
- filterRowKey(Cell) - Method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
- filterRowKey(Cell) - Method in class org.apache.hadoop.hbase.filter.ColumnPrefixFilter
- filterRowKey(Cell) - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
- filterRowKey(Cell) - Method in class org.apache.hadoop.hbase.filter.ColumnValueFilter
- filterRowKey(Cell) - Method in class org.apache.hadoop.hbase.filter.CompareFilter
- filterRowKey(Cell) - Method in class org.apache.hadoop.hbase.filter.Filter
-
Filters a row based on the row key.
- filterRowKey(Cell) - Method in class org.apache.hadoop.hbase.filter.FilterAllFilter
- filterRowKey(Cell) - Method in class org.apache.hadoop.hbase.filter.FilterBase
- filterRowKey(Cell) - Method in class org.apache.hadoop.hbase.filter.FilterList
- filterRowKey(Cell) - Method in class org.apache.hadoop.hbase.filter.FilterListWithAND
- filterRowKey(Cell) - Method in class org.apache.hadoop.hbase.filter.FilterListWithOR
- filterRowKey(Cell) - Method in class org.apache.hadoop.hbase.filter.FilterWrapper
- filterRowKey(Cell) - Method in class org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
- filterRowKey(Cell) - Method in class org.apache.hadoop.hbase.filter.InclusiveStopFilter
- filterRowKey(Cell) - Method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter
- filterRowKey(Cell) - Method in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
- filterRowKey(Cell) - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter
- filterRowKey(Cell) - Method in class org.apache.hadoop.hbase.filter.PageFilter
- filterRowKey(Cell) - Method in class org.apache.hadoop.hbase.filter.PrefixFilter
- filterRowKey(Cell) - Method in class org.apache.hadoop.hbase.filter.RandomRowFilter
- filterRowKey(Cell) - Method in class org.apache.hadoop.hbase.filter.RowFilter
- filterRowKey(Cell) - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
- filterRowKey(Cell) - Method in class org.apache.hadoop.hbase.filter.SkipFilter
- filterRowKey(Cell) - Method in class org.apache.hadoop.hbase.filter.TimestampsFilter
- filterRowKey(Cell) - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
- filters - Variable in class org.apache.hadoop.hbase.filter.FilterListBase
- org.apache.hadoop.hbase.filter.FilterWrapper - Class in org.apache.hadoop.hbase.filter
-
This is a Filter wrapper class which is used in the server side.
- FilterWrapper(Filter) - Constructor for class org.apache.hadoop.hbase.filter.FilterWrapper
-
Constructor.
- org.apache.hadoop.hbase.filter.FilterWrapper.FilterRowRetCode - Enum Class in org.apache.hadoop.hbase.filter
- finalizeWriter(StoreFileWriter, long, MonitoredTask) - Method in class org.apache.hadoop.hbase.mob.DefaultMobStoreFlusher
- finalizeWriter(StoreFileWriter, long, MonitoredTask) - Method in class org.apache.hadoop.hbase.regionserver.DefaultStoreFlusher
- findArchivedLog(Path, Configuration) - Static method in class org.apache.hadoop.hbase.wal.AbstractFSWALProvider
-
Find the archived WAL file path if it is not able to locate in WALs dir.
- findBigRanges(Collection<R>, int) - Static method in class org.apache.hadoop.hbase.util.RegionSplitCalculator
-
Find specified number of top ranges in a big overlap group.
- findCommonPrefix(byte[], byte[], int, int, int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
- findCommonPrefix(byte[], int, int, byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Find length of common prefix in two arrays.
- findCommonPrefix(ByteBuffer, int, int, byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Find length of common prefix in two arrays.
- findCommonPrefix(ByteBuffer, int, int, ByteBuffer, int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Find length of common prefix in two arrays.
- findCommonPrefixInFlatKey(ExtendedCell, ExtendedCell, boolean, boolean) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
Find length of common prefix in keys of the cells, considering key as byte[] if serialized in
KeyValue
. - findConstructor(Class<T>, Object...) - Static method in class org.apache.hadoop.hbase.util.ReflectionUtils
- findCoprocessor(Class<T>) - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
- findCoprocessor(String) - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
-
Find coprocessors by full class name or simple name.
- findCoprocessorEnvironment(String) - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
-
Find a coprocessor environment by class name
- findCoprocessors(Class<T>) - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
-
Find list of coprocessors that extend/implement the given class/interface
- findEntry(byte[], int, int) - Method in interface org.apache.hadoop.hbase.io.util.Dictionary
-
Finds the index of an entry.
- findEntry(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.util.LRUDictionary
- findEntry(ByteBuffer, int, int) - Method in interface org.apache.hadoop.hbase.io.util.Dictionary
-
Finds the index of an entry.
- findEntry(ByteBuffer, int, int) - Method in class org.apache.hadoop.hbase.io.util.LRUDictionary
- findException(Object) - Static method in class org.apache.hadoop.hbase.exceptions.ClientExceptionsUtil
-
Look for an exception we know in the remote exception: - hadoop.ipc wrapped exceptions - nested exceptions Looks for: RegionMovedException / RegionOpeningException / RegionTooBusyException / RpcThrottlingException
- findLastTableState(TableName) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- findPort - Variable in class org.apache.hadoop.hbase.http.HttpServer
- findRegionsForTable(TableName) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.
- findServerWithSameHostnamePortWithLock(ServerName) - Method in class org.apache.hadoop.hbase.master.ServerManager
-
Assumes onlineServers is locked.
- finish() - Method in class org.apache.hadoop.hbase.io.compress.ReusableStreamGzipCodec.ReusableGzipOutputStream
- finish(String) - Method in class org.apache.hadoop.hbase.regionserver.throttle.NoLimitThroughputController
- finish(String) - Method in class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareThroughputController
- finish(String) - Method in interface org.apache.hadoop.hbase.regionserver.throttle.ThroughputController
-
Finish the controller.
- finish(BiConsumer<String, String>, Consumer<String>) - Method in class org.apache.hadoop.hbase.regionserver.storefiletracker.ModifyStoreFileTrackerProcedure
- finish(Map<byte[], List<Cell>>) - Method in class org.apache.hadoop.hbase.regionserver.throttle.StoreHotnessProtector
- finish(ServerName, String) - Method in interface org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination.TaskFinisher
-
finish the partially done task.
- finishClose(FixedFileTrailer) - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterImpl
- finishFileInfo() - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterImpl
- finishInit(Configuration) - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterImpl
-
Additional initialization steps
- finishRegionProcedure(long) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
See
HRegionServer.submitRegionProcedure(long)
. - finishSplitLogFile(String, Configuration) - Static method in class org.apache.hadoop.hbase.wal.WALSplitUtil
-
Completes the work done by splitLogFile by archiving logs
- first - Variable in class org.apache.hadoop.hbase.util.Pair
- first() - Method in class org.apache.hadoop.hbase.regionserver.CellSet
- FIRST_CHAR - Static variable in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- FIRST_META_REGIONINFO - Static variable in class org.apache.hadoop.hbase.client.RegionInfoBuilder
-
RegionInfo for first meta region You cannot use this builder to make an instance of the
RegionInfoBuilder.FIRST_META_REGIONINFO
. - FIRST_REGION_STARTKEY_NOT_EMPTY - Enum constant in enum class org.apache.hadoop.hbase.util.HbckErrorReporter.ERROR_CODE
-
Deprecated.
- firstCellInBlock - Variable in class org.apache.hadoop.hbase.io.hfile.HFileWriterImpl
-
First cell in a block.
- firstEntry() - Method in class org.apache.hadoop.hbase.regionserver.CellFlatMap
- firstEntry() - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
- firstKey() - Method in class org.apache.hadoop.hbase.io.hfile.HFileInfo
- firstKey() - Method in class org.apache.hadoop.hbase.regionserver.CellFlatMap
- firstKey() - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
- org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter - Class in org.apache.hadoop.hbase.filter
-
A filter that will only return the first KV from each row.
- FirstKeyOnlyFilter() - Constructor for class org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
- org.apache.hadoop.hbase.io.hfile.FirstLevelBlockCache - Interface in org.apache.hadoop.hbase.io.hfile
-
In-memory BlockCache that may be backed by secondary layer(s).
- firstRow() - Method in class org.apache.hadoop.hbase.util.RegionSplitter.NumberStringSplit
- firstRow() - Method in interface org.apache.hadoop.hbase.util.RegionSplitter.SplitAlgorithm
-
In HBase, the first row is represented by an empty byte array.
- firstRow() - Method in class org.apache.hadoop.hbase.util.RegionSplitter.UniformSplit
- FIXED_OVERHEAD - Static variable in class org.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValue
- FIXED_OVERHEAD - Static variable in class org.apache.hadoop.hbase.ByteBufferKeyValue
- FIXED_OVERHEAD - Static variable in class org.apache.hadoop.hbase.io.hfile.BlockCacheKey
- FIXED_OVERHEAD - Static variable in class org.apache.hadoop.hbase.io.hfile.HFileBlock
- FIXED_OVERHEAD - Static variable in class org.apache.hadoop.hbase.io.hfile.HFileContext
- FIXED_OVERHEAD - Static variable in class org.apache.hadoop.hbase.KeyValue
- FIXED_OVERHEAD - Static variable in class org.apache.hadoop.hbase.regionserver.AbstractMemStore
- FIXED_OVERHEAD - Static variable in class org.apache.hadoop.hbase.regionserver.CompactionPipeline
- FIXED_OVERHEAD - Static variable in class org.apache.hadoop.hbase.regionserver.DefaultMemStore
- FIXED_OVERHEAD - Static variable in class org.apache.hadoop.hbase.regionserver.HRegion
- FIXED_OVERHEAD - Static variable in class org.apache.hadoop.hbase.regionserver.HStore
- FIXED_OVERHEAD - Static variable in class org.apache.hadoop.hbase.regionserver.ScanInfo
- FIXED_OVERHEAD - Static variable in class org.apache.hadoop.hbase.regionserver.Segment
- FIXED_OVERHEAD - Static variable in class org.apache.hadoop.hbase.regionserver.StoreContext
- FIXED_OVERHEAD - Static variable in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
- FIXED_OVERHEAD - Static variable in class org.apache.hadoop.hbase.SizeCachedByteBufferKeyValue
- FIXED_OVERHEAD - Static variable in class org.apache.hadoop.hbase.SizeCachedNoTagsByteBufferKeyValue
- FIXED_SIZE - Static variable in class org.apache.hadoop.hbase.regionserver.MultiVersionConcurrencyControl
- FIXED_SIZE - Static variable in class org.apache.hadoop.hbase.regionserver.throttle.StoreHotnessProtector
- org.apache.hadoop.hbase.io.hfile.FixedFileTrailer - Class in org.apache.hadoop.hbase.io.hfile
-
The
HFile
has a fixed trailer which contains offsets to other variable parts of the file. - org.apache.hadoop.hbase.quotas.FixedIntervalRateLimiter - Class in org.apache.hadoop.hbase.quotas
-
With this limiter resources will be refilled only after a fixed interval of time.
- FixedIntervalRateLimiter() - Constructor for class org.apache.hadoop.hbase.quotas.FixedIntervalRateLimiter
- FixedIntervalRateLimiter(long) - Constructor for class org.apache.hadoop.hbase.quotas.FixedIntervalRateLimiter
- org.apache.hadoop.hbase.types.FixedLengthWrapper<T> - Class in org.apache.hadoop.hbase.types
-
Wraps an existing
DataType
implementation as a fixed-length version of itself. - FixedLengthWrapper(DataType<T>, int) - Constructor for class org.apache.hadoop.hbase.types.FixedLengthWrapper
-
Create a fixed-length version of the
wrapped
. - fixEmptyMetaCells() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.To fix the empty REGIONINFO_QUALIFIER rows from hbase:meta
- fixMeta() - Method in class org.apache.hadoop.hbase.client.HBaseHbck
- fixMeta() - Method in interface org.apache.hadoop.hbase.client.Hbck
-
Fix Meta.
- fixMeta(RpcController, MasterProtos.FixMetaRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- fixMetaHoleOnlineAndAddReplicas(Configuration, RegionInfo, Collection<ServerName>, int) - Static method in class org.apache.hadoop.hbase.util.HBaseFsckRepair
-
Puts the specified RegionInfo into META with replica related columns
- fixMultiAssignment(Connection, RegionInfo, List<ServerName>) - Static method in class org.apache.hadoop.hbase.util.HBaseFsckRepair
-
Fix multiple assignment by doing silent closes on each RS hosting the region and then force ZK unassigned node to OFFLINE to trigger assignment by master.
- fixOrphanTables() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.To fix orphan table by creating a .tableinfo file under tableDir
1. - fixUnassigned(Admin, RegionInfo) - Static method in class org.apache.hadoop.hbase.util.HBaseFsckRepair
-
Fix unassigned by creating/transition the unassigned ZK node for this region to OFFLINE state with a special flag to tell the master that this is a forced operation by HBCK.
- fixUnDeletedQueues() - Method in class org.apache.hadoop.hbase.util.hbck.ReplicationChecker
- Flat(Random, int, int) - Constructor for class org.apache.hadoop.hbase.util.RandomDistribution.Flat
-
Generate random integers from min (inclusive) to max (exclusive) following even distribution.
- FLATTEN - Enum constant in enum class org.apache.hadoop.hbase.regionserver.MemStoreCompactionStrategy.Action
- FLATTEN_COUNT_UNIQUE_KEYS - Enum constant in enum class org.apache.hadoop.hbase.regionserver.MemStoreCompactionStrategy.Action
- flattenOneSegment(long, CompactingMemStore.IndexType, MemStoreCompactionStrategy.Action) - Method in class org.apache.hadoop.hbase.regionserver.CompactionPipeline
-
If the caller holds the current version, go over the the pipeline and try to flatten each segment.
- flattenOneSegment(long, MemStoreCompactionStrategy.Action) - Method in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
- fLength - Variable in class org.apache.hadoop.hbase.ExtendedCellBuilderImpl
- FLOAT - Enum constant in enum class org.apache.hadoop.hbase.hbtop.field.FieldValueType
- floor(T) - Method in class org.apache.hadoop.hbase.regionserver.CellSet
- floorEntry(K) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
- floorEntry(T) - Method in class org.apache.hadoop.hbase.regionserver.CellFlatMap
- floorKey(K) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
- floorKey(T) - Method in class org.apache.hadoop.hbase.regionserver.CellFlatMap
- flush() - Method in interface org.apache.hadoop.hbase.client.AsyncBufferedMutator
-
Executes all the buffered, asynchronous operations.
- flush() - Method in interface org.apache.hadoop.hbase.client.BufferedMutator
-
Executes all the buffered, asynchronous
Mutation
operations and waits until they are done. - flush() - Method in class org.apache.hadoop.hbase.codec.BaseEncoder
- flush() - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Flushes all caches in the mini hbase cluster
- flush() - Method in class org.apache.hadoop.hbase.io.ByteBufferOutputStream
- flush() - Method in class org.apache.hadoop.hbase.io.ByteBufferWriterOutputStream
- flush() - Method in interface org.apache.hadoop.hbase.io.CellOutputStream
-
Let the implementation decide what to do.
- flush() - Method in class org.apache.hadoop.hbase.io.compress.ReusableStreamGzipCodec.ReusableGzipOutputStream
- flush() - Method in class org.apache.hadoop.hbase.io.encoding.RowIndexEncoderV1
- flush() - Method in interface org.apache.hadoop.hbase.util.JSONBean.Writer
- flush(boolean) - Method in interface org.apache.hadoop.hbase.io.asyncfs.AsyncFSOutput
-
Flush the buffer out.
- flush(boolean) - Method in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutput
-
Flush the buffer out to datanodes.
- flush(boolean) - Method in class org.apache.hadoop.hbase.io.asyncfs.WrapperAsyncFSOutput
- flush(boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Flush the cache.
- flush(byte[], boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncClusterConnection
-
Flush a region and get the response.
- flush(PrintWriter) - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.ScreenBuffer
- flush(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Flush a table.
- flush(TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Flush a table.
- flush(TableName) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Flushes all caches in the mini hbase cluster
- flush(TableName, byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Flush the specified column family stores on all regions of the passed table.
- flush(TableName, byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Flush the specified column family stores on all regions of the passed table.
- flush(TableName, List<byte[]>) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Flush the specified column family stores on all regions of the passed table.
- flush(TableName, List<byte[]>) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Flush the specified column family stores on all regions of the passed table.
- FLUSH - Enum constant in enum class org.apache.hadoop.hbase.client.SnapshotType
- FLUSH - Static variable in class org.apache.hadoop.hbase.wal.WALEdit
-
Deprecated.Since 2.3.0. Make it protected, internal-use only.
- FLUSH_MEMSTORE_SIZE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- FLUSH_MEMSTORE_SIZE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- FLUSH_OUTPUT_SIZE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- FLUSH_OUTPUT_SIZE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- FLUSH_POLICY - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
- FLUSH_QUEUE_LENGTH - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- FLUSH_QUEUE_LENGTH_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- FLUSH_TIME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- FLUSH_TIME_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- FLUSH_TO_L0_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.StripeStoreConfig
-
Whether to flush memstore to L0 files, or directly to stripes.
- org.apache.hadoop.hbase.regionserver.FlushAllLargeStoresPolicy - Class in org.apache.hadoop.hbase.regionserver
-
A
FlushPolicy
that only flushes store larger a given threshold. - FlushAllLargeStoresPolicy() - Constructor for class org.apache.hadoop.hbase.regionserver.FlushAllLargeStoresPolicy
- org.apache.hadoop.hbase.regionserver.FlushAllStoresPolicy - Class in org.apache.hadoop.hbase.regionserver
-
A
FlushPolicy
that always flushes all stores for a given region. - FlushAllStoresPolicy() - Constructor for class org.apache.hadoop.hbase.regionserver.FlushAllStoresPolicy
- flushcache() - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.Call flushCache on all regions on all participating regionservers.
- flushcache(boolean, boolean, FlushLifeCycleTracker) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
- flushcache(List<byte[]>, boolean, FlushLifeCycleTracker) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Flush the cache.
- flushcache(TableName) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.Call flushCache on all regions of the specified table.
- flushCache(long, MemStoreSnapshot, MonitoredTask, ThroughputController, FlushLifeCycleTracker, Consumer<Path>) - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
Write out current snapshot.
- flushed - Variable in class org.apache.hadoop.hbase.codec.BaseEncoder
- FLUSHED_CELLS - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- FLUSHED_CELLS_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- FLUSHED_CELLS_SIZE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- FLUSHED_CELLS_SIZE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- FLUSHED_COMPACTION_NEEDED - Enum constant in enum class org.apache.hadoop.hbase.regionserver.HRegion.FlushResult.Result
- FLUSHED_MEMSTORE_BYTES - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- FLUSHED_MEMSTORE_BYTES_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- FLUSHED_NO_COMPACTION_NEEDED - Enum constant in enum class org.apache.hadoop.hbase.regionserver.HRegion.FlushResult.Result
- FLUSHED_OUTPUT_BYTES - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- FLUSHED_OUTPUT_BYTES_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- FLUSHEDSEQUENCEID_FLUSHER_INTERVAL - Static variable in class org.apache.hadoop.hbase.master.ServerManager
- FLUSHEDSEQUENCEID_FLUSHER_INTERVAL_DEFAULT - Static variable in class org.apache.hadoop.hbase.master.ServerManager
- FLUSHES_QUEUED_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
- FLUSHES_QUEUED_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
- flushInMemory(MutableSegment) - Method in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
- org.apache.hadoop.hbase.regionserver.FlushLargeStoresPolicy - Class in org.apache.hadoop.hbase.regionserver
-
A
FlushPolicy
that only flushes store larger a given threshold. - FlushLargeStoresPolicy() - Constructor for class org.apache.hadoop.hbase.regionserver.FlushLargeStoresPolicy
- org.apache.hadoop.hbase.regionserver.FlushLifeCycleTracker - Interface in org.apache.hadoop.hbase.regionserver
-
Used to track flush execution.
- flushMasterStore() - Method in interface org.apache.hadoop.hbase.client.Admin
-
Flush master local region
- flushMasterStore() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Flush master local region
- flushMasterStore() - Method in class org.apache.hadoop.hbase.master.HMaster
- flushMasterStore() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Flush master local region
- flushMasterStore(RpcController, MasterProtos.FlushMasterStoreRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- org.apache.hadoop.hbase.regionserver.FlushNonSloppyStoresFirstPolicy - Class in org.apache.hadoop.hbase.regionserver
-
A
FlushPolicy
that only flushes store larger than a given threshold. - FlushNonSloppyStoresFirstPolicy() - Constructor for class org.apache.hadoop.hbase.regionserver.FlushNonSloppyStoresFirstPolicy
- org.apache.hadoop.hbase.regionserver.FlushPolicy - Class in org.apache.hadoop.hbase.regionserver
-
A flush policy determines the stores that need to be flushed when flushing a region.
- FlushPolicy() - Constructor for class org.apache.hadoop.hbase.regionserver.FlushPolicy
- org.apache.hadoop.hbase.regionserver.FlushPolicyFactory - Class in org.apache.hadoop.hbase.regionserver
-
The class that creates a flush policy from a conf and HTableDescriptor.
- FlushPolicyFactory() - Constructor for class org.apache.hadoop.hbase.regionserver.FlushPolicyFactory
- flushRegion(byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Flush an individual region.
- flushRegion(byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Flush an individual region.
- flushRegion(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Flush a column family within a region.
- flushRegion(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Flush a column family within a region.
- flushRegion(AdminProtos.FlushRegionRequest) - Method in class org.apache.hadoop.hbase.client.AsyncRegionServerAdmin
- flushRegion(RpcController, AdminProtos.FlushRegionRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- flushRegion(RpcController, AdminProtos.FlushRegionRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
Flush a region on the region server.
- org.apache.hadoop.hbase.regionserver.FlushRegionCallable - Class in org.apache.hadoop.hbase.regionserver
- FlushRegionCallable() - Constructor for class org.apache.hadoop.hbase.regionserver.FlushRegionCallable
- flushRegionServer(ServerName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Flush all regions on the region server.
- flushRegionServer(ServerName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Flush all region on the region server.
- flushRegionsIfNecessary(Configuration) - Static method in class org.apache.hadoop.hbase.mapreduce.Import
-
If the durability is set to
Durability.SKIP_WAL
and the data is imported to hbase, we need to flush all the regions of the table as the data is held in memory and is also not present in the Write Ahead Log to replay in scenarios of a crash. - flushRequested(FlushType, Region) - Method in interface org.apache.hadoop.hbase.regionserver.FlushRequestListener
-
Callback which will get called when a flush request is made for a region.
- org.apache.hadoop.hbase.regionserver.FlushRequester - Interface in org.apache.hadoop.hbase.regionserver
-
Request a flush.
- org.apache.hadoop.hbase.regionserver.FlushRequestListener - Interface in org.apache.hadoop.hbase.regionserver
-
Listener which will get notified regarding flush requests of regions.
- flushSizeLowerBound - Variable in class org.apache.hadoop.hbase.regionserver.FlushLargeStoresPolicy
- flushSnapshot(MemStoreSnapshot, long, MonitoredTask, ThroughputController, FlushLifeCycleTracker, Consumer<Path>) - Method in class org.apache.hadoop.hbase.mob.DefaultMobStoreFlusher
-
Flushes the snapshot of the MemStore.
- flushSnapshot(MemStoreSnapshot, long, MonitoredTask, ThroughputController, FlushLifeCycleTracker, Consumer<Path>) - Method in class org.apache.hadoop.hbase.regionserver.DefaultStoreFlusher
- flushSnapshot(MemStoreSnapshot, long, MonitoredTask, ThroughputController, FlushLifeCycleTracker, Consumer<Path>) - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFlusher
- flushTable(TableName, List<byte[]>, long, long) - Method in class org.apache.hadoop.hbase.master.HMaster
- flushTable(TableName, List<byte[]>, long, long) - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Flush an existing table
- flushTable(RpcController, MasterProtos.FlushTableRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- org.apache.hadoop.hbase.regionserver.throttle.FlushThroughputControllerFactory - Class in org.apache.hadoop.hbase.regionserver.throttle
- fOffset - Variable in class org.apache.hadoop.hbase.ExtendedCellBuilderImpl
- FORCE - Enum constant in enum class org.apache.hadoop.hbase.master.SplitLogManager.ResubmitDirective
-
Deprecated.
- forceCopyOfBigCellInto(ExtendedCell) - Method in class org.apache.hadoop.hbase.regionserver.ImmutableMemStoreLAB
-
The process of merging assumes all cells are allocated on mslab.
- forceCopyOfBigCellInto(ExtendedCell) - Method in interface org.apache.hadoop.hbase.regionserver.MemStoreLAB
-
Allocates slice in this LAB and copy the passed Cell into this area.
- forceCopyOfBigCellInto(ExtendedCell) - Method in class org.apache.hadoop.hbase.regionserver.MemStoreLABImpl
-
When a cell's size is too big (bigger than maxAlloc), copyCellInto does not allocate it on MSLAB.
- forceRecompute() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Force a re-computation of the metrics.
- org.apache.hadoop.hbase.errorhandling.ForeignException - Exception in org.apache.hadoop.hbase.errorhandling
-
A ForeignException is an exception from another thread or process.
- ForeignException(String, String) - Constructor for exception org.apache.hadoop.hbase.errorhandling.ForeignException
-
Create a new ForeignException that can be serialized.
- ForeignException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.errorhandling.ForeignException
-
Create a new ForeignException that can be serialized.
- org.apache.hadoop.hbase.errorhandling.ForeignExceptionDispatcher - Class in org.apache.hadoop.hbase.errorhandling
-
The dispatcher acts as the state holding entity for foreign error handling.
- ForeignExceptionDispatcher() - Constructor for class org.apache.hadoop.hbase.errorhandling.ForeignExceptionDispatcher
- ForeignExceptionDispatcher(String) - Constructor for class org.apache.hadoop.hbase.errorhandling.ForeignExceptionDispatcher
- org.apache.hadoop.hbase.errorhandling.ForeignExceptionListener - Interface in org.apache.hadoop.hbase.errorhandling
-
The ForeignExceptionListener is an interface for objects that can receive a ForeignException.
- org.apache.hadoop.hbase.errorhandling.ForeignExceptionSnare - Interface in org.apache.hadoop.hbase.errorhandling
-
This is an interface for a cooperative exception throwing mechanism.
- FOREVER - Static variable in class org.apache.hadoop.hbase.HConstants
-
Unlimited time-to-live.
- format() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.Header
- format(int) - Static method in class org.apache.hadoop.hbase.PerformanceEvaluation
- format(String, PrettyPrinter.Unit) - Static method in class org.apache.hadoop.hbase.util.PrettyPrinter
- FORMAT_VERSION_KEY - Static variable in class org.apache.hadoop.hbase.io.hfile.HFile
-
The configuration key for HFile version to use for new files
- formatBulkloadSeqId(long) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
- formatDate(Date) - Static method in class org.apache.hadoop.hbase.mob.MobUtils
-
Formats a date to a string.
- formatLogFilters(List<Filter>) - Method in class org.apache.hadoop.hbase.filter.FilterListBase
- formatLogFilters(List<Filter>) - Method in class org.apache.hadoop.hbase.filter.FilterListWithAND
- formatLogFilters(List<Filter>) - Method in class org.apache.hadoop.hbase.filter.FilterListWithOR
- formatStats(BloomFilterBase) - Static method in class org.apache.hadoop.hbase.util.BloomFilterUtil
-
A human-readable string with statistics for the given Bloom filter.
- formatTestingStats() - Method in class org.apache.hadoop.hbase.io.hfile.CompoundBloomFilter
- forwardNextCellHint - Variable in class org.apache.hadoop.hbase.filter.PrefixFilter
- foundColumn - Variable in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
- FRAMED_CONF_DEFAULT - Static variable in class org.apache.hadoop.hbase.thrift.Constants
- FRAMED_CONF_KEY - Static variable in class org.apache.hadoop.hbase.thrift.Constants
- FRAMED_OPTION - Static variable in class org.apache.hadoop.hbase.thrift.Constants
- free() - Method in interface org.apache.hadoop.hbase.io.ByteBuffAllocator.Recycler
- freeDirectBuffer(ByteBuffer) - Static method in class org.apache.hadoop.hbase.util.UnsafeAccess
- from(long) - Static method in class org.apache.hadoop.hbase.io.TimeRange
-
Represents the time interval [minStamp, Long.MAX_VALUE)
- fromArrays(Collection<byte[]>) - Static method in class org.apache.hadoop.hbase.util.ByteRangeUtils
- fromByte(byte) - Static method in enum class org.apache.hadoop.hbase.client.IsolationLevel
- fromByteArray(byte[]) - Static method in class org.apache.hadoop.hbase.backup.BackupInfo
- fromBytes(byte[]) - Static method in enum class org.apache.hadoop.hbase.client.IsolationLevel
- fromDeleteType(ClientProtos.MutationProto.DeleteType) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Convert a protocol buffer DeleteType to delete KeyValue type.
- fromFilename(String) - Static method in enum class org.apache.hadoop.hbase.io.crypto.tls.KeyStoreFileType
-
Detects the type of KeyStore / TrustStore file from the file extension.
- fromHex(String) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Create a byte array from a string of hash digits.
- fromJson(String, Class<T>) - Static method in class org.apache.hadoop.hbase.util.JsonMapper
- fromList(List<Tag>) - Static method in class org.apache.hadoop.hbase.TagUtil
-
Write a list of tags into a byte array Note : these are all purely internal APIs.
- fromParts(String, int) - Static method in class org.apache.hadoop.hbase.net.Address
- fromPropertyValue(String) - Static method in enum class org.apache.hadoop.hbase.io.crypto.tls.KeyStoreFileType
-
Converts a property value to a StoreFileType enum.
- fromPropertyValue(String) - Static method in enum class org.apache.hadoop.hbase.io.crypto.tls.X509Util.ClientAuth
-
Converts a property value to a ClientAuth enum.
- fromPropertyValueOrFileName(String, String) - Static method in enum class org.apache.hadoop.hbase.io.crypto.tls.KeyStoreFileType
-
If
propertyValue
is not null or empty, returns the result ofKeyStoreFileType.fromPropertyValue(propertyValue)
. - fromProto(BackupProtos.BackupInfo) - Static method in class org.apache.hadoop.hbase.backup.BackupInfo
- fromRow(byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncTable.CoprocessorServiceBuilder
-
Specify a start row
- fromRow(byte[], boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncTable.CoprocessorServiceBuilder
-
Specify a start row
- fromRowSpec(String, RowSpec, Filter, boolean) - Static method in class org.apache.hadoop.hbase.rest.ResultGenerator
- fromSocketAddress(InetSocketAddress) - Static method in class org.apache.hadoop.hbase.net.Address
- fromStream(InputStream) - Static method in class org.apache.hadoop.hbase.backup.BackupInfo
- fromString(String) - Static method in enum class org.apache.hadoop.hbase.CatalogReplicaMode
- fromString(String) - Method in enum class org.apache.hadoop.hbase.http.HttpConfig.Policy
- fromString(String) - Static method in class org.apache.hadoop.hbase.net.Address
- fromTableThrottles(TableName, QuotaProtos.Throttle) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
- fromThrottle(String, TableName, String, String, QuotaProtos.Throttle) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
- fromThrottle(QuotaProtos.Throttle) - Static method in class org.apache.hadoop.hbase.quotas.QuotaLimiterFactory
- fs - Variable in class org.apache.hadoop.hbase.io.hfile.HFile.WriterFactory
- fs - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
file system instance
- fs - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractProtobufWALReader
- FS_PREAD_TIME_HISTO_DESC - Static variable in interface org.apache.hadoop.hbase.io.MetricsIOSource
- FS_PREAD_TIME_HISTO_KEY - Static variable in interface org.apache.hadoop.hbase.io.MetricsIOSource
- FS_READ_TIME_HISTO_DESC - Static variable in interface org.apache.hadoop.hbase.io.MetricsIOSource
- FS_READ_TIME_HISTO_KEY - Static variable in interface org.apache.hadoop.hbase.io.MetricsIOSource
- FS_SHUTDOWN_HOOK_WAIT - Static variable in class org.apache.hadoop.hbase.regionserver.ShutdownHook
-
Key for a long configuration on how much time to wait on the fs shutdown hook.
- FS_WRITE_HISTO_KEY - Static variable in interface org.apache.hadoop.hbase.io.MetricsIOSource
- FS_WRITE_TIME_HISTO_DESC - Static variable in interface org.apache.hadoop.hbase.io.MetricsIOSource
- fsBlockReader - Variable in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
-
Filesystem-level block reader.
- org.apache.hadoop.hbase.io.FSDataInputStreamWrapper - Class in org.apache.hadoop.hbase.io
-
Wrapper for input stream(s) that takes care of the interaction of FS and HBase checksums, as well as closing streams.
- FSDataInputStreamWrapper(FileSystem, Path) - Constructor for class org.apache.hadoop.hbase.io.FSDataInputStreamWrapper
- FSDataInputStreamWrapper(FileSystem, Path, boolean, long) - Constructor for class org.apache.hadoop.hbase.io.FSDataInputStreamWrapper
- FSDataInputStreamWrapper(FileSystem, FileLink, boolean, long) - Constructor for class org.apache.hadoop.hbase.io.FSDataInputStreamWrapper
- FSDataInputStreamWrapper(FSDataInputStream) - Constructor for class org.apache.hadoop.hbase.io.FSDataInputStreamWrapper
-
For use in tests.
- FSDataInputStreamWrapper(FSDataInputStream, FSDataInputStream) - Constructor for class org.apache.hadoop.hbase.io.FSDataInputStreamWrapper
-
For use in tests.
- org.apache.hadoop.hbase.regionserver.wal.FSHLog - Class in org.apache.hadoop.hbase.regionserver.wal
-
The original implementation of FSWAL.
- FSHLog(FileSystem, Path, String, String, Configuration, List<WALActionsListener>, boolean, String, String) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.FSHLog
- FSHLog(FileSystem, Path, String, Configuration) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.FSHLog
-
Constructor.
- FSHLog(FileSystem, Abortable, Path, String, String, Configuration, List<WALActionsListener>, boolean, String, String, FileSystem, Path) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.FSHLog
-
Create an edit log at the given
dir
location. - FSHLog(FileSystem, Abortable, Path, String, Configuration) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.FSHLog
- org.apache.hadoop.hbase.wal.FSHLogProvider - Class in org.apache.hadoop.hbase.wal
-
A WAL provider that use
FSHLog
. - FSHLogProvider() - Constructor for class org.apache.hadoop.hbase.wal.FSHLogProvider
- org.apache.hadoop.hbase.wal.FSHLogProvider.Writer - Interface in org.apache.hadoop.hbase.wal
- org.apache.hadoop.hbase.replication.FSReplicationPeerStorage - Class in org.apache.hadoop.hbase.replication
-
A filesystem based replication peer storage.
- FSReplicationPeerStorage(FileSystem, Configuration) - Constructor for class org.apache.hadoop.hbase.replication.FSReplicationPeerStorage
- org.apache.hadoop.hbase.util.FSTableDescriptors - Class in org.apache.hadoop.hbase.util
-
Implementation of
TableDescriptors
that reads descriptors from the passed filesystem. - FSTableDescriptors(Configuration) - Constructor for class org.apache.hadoop.hbase.util.FSTableDescriptors
-
Construct a FSTableDescriptors instance using the hbase root dir of the given conf and the filesystem where that root dir lives.
- FSTableDescriptors(FileSystem, Path) - Constructor for class org.apache.hadoop.hbase.util.FSTableDescriptors
- FSTableDescriptors(FileSystem, Path, boolean, boolean) - Constructor for class org.apache.hadoop.hbase.util.FSTableDescriptors
- FSTableDescriptors(FileSystem, Path, boolean, boolean, int) - Constructor for class org.apache.hadoop.hbase.util.FSTableDescriptors
- org.apache.hadoop.hbase.util.FSUtils - Class in org.apache.hadoop.hbase.util
-
Utility methods for interacting with the underlying file system.
- org.apache.hadoop.hbase.util.FSUtils.BlackListDirFilter - Class in org.apache.hadoop.hbase.util
-
Directory filter that doesn't include any of the directories in the specified blacklist
- org.apache.hadoop.hbase.util.FSUtils.DirFilter - Class in org.apache.hadoop.hbase.util
-
A
PathFilter
that only allows directories. - org.apache.hadoop.hbase.util.FSUtils.FamilyDirFilter - Class in org.apache.hadoop.hbase.util
-
Filter for all dirs that are legal column family names.
- org.apache.hadoop.hbase.util.FSUtils.HFileFilter - Class in org.apache.hadoop.hbase.util
-
Filter for HFiles that excludes reference files.
- org.apache.hadoop.hbase.util.FSUtils.HFileLinkFilter - Class in org.apache.hadoop.hbase.util
-
Filter for HFileLinks (StoreFiles and HFiles not included).
- org.apache.hadoop.hbase.util.FSUtils.ReferenceAndLinkFileFilter - Class in org.apache.hadoop.hbase.util
- org.apache.hadoop.hbase.util.FSUtils.ReferenceFileFilter - Class in org.apache.hadoop.hbase.util
- org.apache.hadoop.hbase.util.FSUtils.RegionDirFilter - Class in org.apache.hadoop.hbase.util
-
Filter for all dirs that don't start with '.'
- org.apache.hadoop.hbase.util.FSUtils.UserTableDirFilter - Class in org.apache.hadoop.hbase.util
-
A
PathFilter
that returns usertable directories. - org.apache.hadoop.hbase.util.FSVisitor - Class in org.apache.hadoop.hbase.util
-
Utility methods for interacting with the hbase.root file system.
- org.apache.hadoop.hbase.util.FSVisitor.StoreFileVisitor - Interface in org.apache.hadoop.hbase.util
- FSYNC_WAL - Enum constant in enum class org.apache.hadoop.hbase.client.Durability
-
Write the Mutation to the WAL synchronously and force the entries to disk.
- FULL - Enum constant in enum class org.apache.hadoop.hbase.backup.BackupType
- FULL_MOB_COMPACTION_TYPE - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
- FULL_RWX_PERMISSIONS - Static variable in class org.apache.hadoop.hbase.util.CommonFSUtils
-
Full access permissions (starting point for a umask)
- fullScanMetaAndPrint(Connection) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
- fullScanRegions(Connection) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Performs a full scan of
hbase:meta
for regions. - fullScanRegions(Connection, ClientMetaTableAccessor.Visitor) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Performs a full scan of
hbase:meta
for regions. - fullScanTables(Connection, ClientMetaTableAccessor.Visitor) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Performs a full scan of
hbase:meta
for tables. - future - Variable in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCaller
- org.apache.hadoop.hbase.util.FutureUtils - Class in org.apache.hadoop.hbase.util
-
Helper class for processing futures.
- fuzzyMatch(String) - Static method in enum class org.apache.hadoop.hbase.util.PoolMap.PoolType
- fuzzyNormalize(String) - Static method in enum class org.apache.hadoop.hbase.util.PoolMap.PoolType
- org.apache.hadoop.hbase.filter.FuzzyRowFilter - Class in org.apache.hadoop.hbase.filter
-
This is optimized version of a standard FuzzyRowFilter Filters data based on fuzzy row key.
- FuzzyRowFilter(List<Pair<byte[], byte[]>>) - Constructor for class org.apache.hadoop.hbase.filter.FuzzyRowFilter
G
- org.apache.hadoop.hbase.metrics.Gauge<T> - Interface in org.apache.hadoop.hbase.metrics
-
A metrics which measures a discrete value.
- GB_IN_BYTES - Static variable in class org.apache.hadoop.hbase.HConstants
- GENERAL_BLOOM_META - Enum constant in enum class org.apache.hadoop.hbase.io.hfile.BlockType
-
General Bloom filter metadata, version 2
- GENERAL_QUEUE_DESC - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
- GENERAL_QUEUE_NAME - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
- generalBloomFilter - Variable in class org.apache.hadoop.hbase.regionserver.StoreFileReader
- generateColumnDescriptors() - Static method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Create a set of column descriptors with the combination of compression, encoding, bloom codecs available.
- generateColumnDescriptors(String) - Static method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Create a set of column descriptors with the combination of compression, encoding, bloom codecs available.
- generateColumnsForCf(byte[], byte[]) - Method in class org.apache.hadoop.hbase.util.MultiThreadedAction.DefaultDataGenerator
- generateData(Random, int) - Static method in class org.apache.hadoop.hbase.PerformanceEvaluation
- generateDeadServersListToSend() - Method in class org.apache.hadoop.hbase.master.ClusterStatusPublisher
-
Create the dead server to send.
- generateExceptionForChecksumFailureForTest(boolean) - Static method in class org.apache.hadoop.hbase.io.hfile.ChecksumUtil
-
Mechanism to throw an exception in case of hbase checksum failure.
- generateFavoredNodes(RegionInfo) - Method in class org.apache.hadoop.hbase.favored.FavoredNodeAssignmentHelper
- generateFavoredNodesForDaughter(List<ServerName>, RegionInfo, RegionInfo, RegionInfo) - Method in class org.apache.hadoop.hbase.favored.FavoredNodeLoadBalancer
- generateFavoredNodesForDaughter(List<ServerName>, RegionInfo, RegionInfo, RegionInfo) - Method in interface org.apache.hadoop.hbase.favored.FavoredNodesPromoter
- generateFavoredNodesForMergedRegion(RegionInfo, RegionInfo[]) - Method in class org.apache.hadoop.hbase.favored.FavoredNodeLoadBalancer
- generateFavoredNodesForMergedRegion(RegionInfo, RegionInfo[]) - Method in interface org.apache.hadoop.hbase.favored.FavoredNodesPromoter
- generateFavoredNodesRoundRobin(Map<ServerName, List<RegionInfo>>, List<RegionInfo>) - Method in class org.apache.hadoop.hbase.favored.FavoredNodeAssignmentHelper
- generateMissingFavoredNode(List<ServerName>) - Method in class org.apache.hadoop.hbase.favored.FavoredNodeAssignmentHelper
- generateMissingFavoredNode(List<ServerName>, List<ServerName>) - Method in class org.apache.hadoop.hbase.favored.FavoredNodeAssignmentHelper
- generateNewScannerId() - Method in class org.apache.hadoop.hbase.regionserver.ScannerIdGenerator
- generateRandomSizeValue(byte[]...) - Method in class org.apache.hadoop.hbase.util.LoadTestKVGenerator
-
Generates a value for the given key index and column qualifier.
- generateSecretKey(Configuration, String, byte[]...) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
-
Return a key derived from the concatenation of the supplied arguments using PBKDF2WithHmacSHA384 key derivation algorithm at 10,000 iterations.
- generateSecretKey(Configuration, String, String...) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
-
Return a key derived from the concatenation of the supplied arguments using PBKDF2WithHmacSHA384 key derivation algorithm at 10,000 iterations.
- generateValue(byte[], byte[], byte[]) - Method in class org.apache.hadoop.hbase.util.LoadTestDataGeneratorWithMOB
- generateValue(byte[], byte[], byte[]) - Method in class org.apache.hadoop.hbase.util.MultiThreadedAction.DefaultDataGenerator
- get() - Static method in class org.apache.hadoop.hbase.client.PerClientRandomNonceGenerator
-
Get the singleton nonce generator.
- get() - Method in class org.apache.hadoop.hbase.client.trace.ConnectionSpanBuilder
- get() - Method in class org.apache.hadoop.hbase.client.trace.IpcClientSpanBuilder
- get() - Method in class org.apache.hadoop.hbase.client.trace.TableOperationSpanBuilder
- get() - Method in class org.apache.hadoop.hbase.client.trace.TableSpanBuilder
- get() - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
-
Get the data from the BytesWritable.
- get() - Method in class org.apache.hadoop.hbase.ipc.BlockingRpcCallback
-
Returns the parameter passed to
BlockingRpcCallback.run(Object)
ornull
if a null value was passed. - get() - Method in class org.apache.hadoop.hbase.ipc.CoprocessorRpcUtils.BlockingRpcCallback
-
Returns the parameter passed to
CoprocessorRpcUtils.BlockingRpcCallback.run(Object)
ornull
if a null value was passed. - get() - Method in class org.apache.hadoop.hbase.JitterScheduledThreadPoolExecutorImpl.JitteredRunnableScheduledFuture
- get() - Method in class org.apache.hadoop.hbase.master.BooleanStateStore
-
Returns true if the flag is on, otherwise false
- get() - Method in interface org.apache.hadoop.hbase.master.HMaster.TableDescriptorGetter
- get() - Method in class org.apache.hadoop.hbase.nio.ByteBuff
-
A relative method that returns byte at the current position.
- get() - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
A relative method that returns byte at the current position.
- get() - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
- get() - Method in class org.apache.hadoop.hbase.server.trace.IpcServerSpanBuilder
- get() - Method in class org.apache.hadoop.hbase.Size
-
get the value
- get() - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
- get() - Method in class org.apache.hadoop.hbase.util.Bytes
-
Get the data from the Bytes.
- get() - Method in interface org.apache.hadoop.hbase.util.IOExceptionSupplier
- get() - Method in interface org.apache.hadoop.hbase.util.PoolMap.PoolResourceSupplier
- get() - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
Retrieve the next byte from this range.
- get() - Method in class org.apache.hadoop.hbase.util.SortedList
-
Returns a reference to the unmodifiable list currently backing the SortedList.
- get(byte[]) - Method in class org.apache.hadoop.hbase.nio.ByteBuff
-
Copies the content from this ByteBuff's current position to the byte array and fills it.
- get(byte[]) - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
Copies the content from this MBB's current position to the byte array and fills it.
- get(byte[]) - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
- get(byte[]) - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
- get(byte[]) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
Fill
dst
with bytes from the range, starting fromposition
. - get(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Mutation
-
Returns a list of all KeyValue objects with matching column family and qualifier.
- get(byte[], int, int) - Method in class org.apache.hadoop.hbase.nio.ByteBuff
-
Copies the specified number of bytes from this ByteBuff's current position to the byte[]'s offset.
- get(byte[], int, int) - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
Copies the specified number of bytes from this MBB's current position to the byte[]'s offset.
- get(byte[], int, int) - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
- get(byte[], int, int) - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
- get(byte[], int, int) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
Fill
dst
with bytes from the range, starting from the currentposition
. - get(int) - Method in class org.apache.hadoop.hbase.nio.ByteBuff
-
Fetches the byte at the given index.
- get(int) - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
Fetches the byte at the given index.
- get(int) - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
- get(int) - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
- get(int) - Method in class org.apache.hadoop.hbase.util.ByteArrayHashKey
- get(int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Retrieve the byte at
index
. - get(int) - Method in class org.apache.hadoop.hbase.util.HashKey
-
Return The byte at the given position in this HashKey
- get(int) - Method in class org.apache.hadoop.hbase.util.RowBloomHashKey
- get(int) - Method in class org.apache.hadoop.hbase.util.RowColBloomHashKey
- get(int) - Method in class org.apache.hadoop.hbase.util.SortedList
- get(int, byte[]) - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
- get(int, byte[]) - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
- get(int, byte[]) - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Fill
dst
with bytes from the range, starting fromindex
. - get(int, byte[]) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
- get(int, byte[]) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
- get(int, byte[]) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
- get(int, byte[], int, int) - Method in class org.apache.hadoop.hbase.nio.ByteBuff
-
Copies the specified number of bytes from this ByteBuff's given position to the byte[]'s offset.
- get(int, byte[], int, int) - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
- get(int, byte[], int, int) - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
- get(int, byte[], int, int) - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
- get(int, byte[], int, int) - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
- get(int, byte[], int, int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Fill
dst
with bytes from the range, starting fromindex
. - get(int, byte[], int, int) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
- get(int, byte[], int, int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
- get(int, byte[], int, int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
- get(long, TimeUnit) - Method in class org.apache.hadoop.hbase.JitterScheduledThreadPoolExecutorImpl.JitteredRunnableScheduledFuture
- get(Object) - Method in class org.apache.hadoop.hbase.hbtop.Record
- get(Object) - Method in class org.apache.hadoop.hbase.io.hfile.HFileInfo
- get(Object) - Method in class org.apache.hadoop.hbase.regionserver.CellFlatMap
- get(Object) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
- get(String) - Method in class org.apache.hadoop.hbase.CompoundConfiguration
- get(String) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
- get(String) - Method in class org.apache.hadoop.hbase.master.TableNamespaceManager
- get(String) - Method in interface org.apache.hadoop.hbase.metrics.MetricRegistry
-
Returns previously registered metric with the name if any.
- get(String) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Send a GET request
- get(String) - Method in class org.apache.hadoop.hbase.zookeeper.ReadOnlyZKClient
- get(String, long) - Method in class org.apache.hadoop.hbase.zookeeper.ReadOnlyZKClient
- get(String, String) - Method in class org.apache.hadoop.hbase.CompoundConfiguration
-
Get the value of the
name
. - get(String, String) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
- get(String, String) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Send a GET request
- get(String, Header[]) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Send a GET request
- get(ByteBuffer, int, int) - Method in class org.apache.hadoop.hbase.nio.ByteBuff
-
Copies the content from this ByteBuff to a ByteBuffer Note : This will advance the position marker of
out
but not change the position maker for this ByteBuff - get(ByteBuffer, int, int) - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
Copies the content from an this MBB to a ByteBuffer
- get(ByteBuffer, int, int) - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
- get(ByteBuffer, ByteBuffer, byte[], byte[], Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
-
Note: this internal interface is slightly different from public APIs in regard to handling of the qualifier.
- get(ByteBuffer, ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
- get(Future<T>) - Static method in class org.apache.hadoop.hbase.util.FutureUtils
-
A helper class for getting the result of a Future, and convert the error to an
IOException
. - get(Future<T>, long, TimeUnit) - Static method in class org.apache.hadoop.hbase.util.FutureUtils
-
A helper class for getting the result of a Future with timeout, and convert the error to an
IOException
. - get(List<Get>) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
Extracts certain cells from the given rows, in batch.
- get(List<Get>) - Method in interface org.apache.hadoop.hbase.client.Table
-
Extracts specified cells from the given rows, as a batch.
- get(ServletContext, UriInfo) - Method in class org.apache.hadoop.hbase.rest.NamespacesInstanceResource
-
Build a response for GET namespace description or GET list of namespace tables.
- get(ServletContext, UriInfo) - Method in class org.apache.hadoop.hbase.rest.NamespacesResource
-
Build a response for a list of all namespaces request.
- get(ServletContext, UriInfo) - Method in class org.apache.hadoop.hbase.rest.VersionResource
-
Build a response for a version request.
- get(K) - Method in class org.apache.hadoop.hbase.util.ObjectPool
-
Returns a shared object associated with the given
key
, which is identified by theequals
method. - get(Cell) - Method in class org.apache.hadoop.hbase.regionserver.CellSet
- get(Connection, Configuration, FileSystem, TableName) - Method in interface org.apache.hadoop.hbase.quotas.FileArchiverNotifierFactory
-
Creates or obtains a
FileArchiverNotifier
instance for the given args. - get(Connection, Configuration, FileSystem, TableName) - Method in class org.apache.hadoop.hbase.quotas.FileArchiverNotifierFactoryImpl
-
Returns the
FileArchiverNotifier
instance for the givenTableName
. - get(Get) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
Extracts certain cells from a given row.
- get(Get) - Method in interface org.apache.hadoop.hbase.client.Table
-
Extracts certain cells from a given row.
- get(Get) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
- get(Get) - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Do a get based on the get parameter.
- get(Get, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
- get(Get, boolean) - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Do a get based on the get parameter.
- get(MetricRegistryInfo) - Method in class org.apache.hadoop.hbase.metrics.MetricRegistries
-
Returns the MetricRegistry if found.
- get(Cluster, String) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Send a GET request
- get(Cluster, String, String) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Send a GET request
- get(Cluster, String, Header[]) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Send a GET request
- get(Size.Unit) - Method in class org.apache.hadoop.hbase.Size
-
get the value which is converted to specified unit.
- get(TableName) - Method in interface org.apache.hadoop.hbase.TableDescriptors
-
Returns TableDescriptor for tablename
- get(TableName) - Method in class org.apache.hadoop.hbase.util.FSTableDescriptors
-
Get the current table descriptor for the given table, or null if none exists.
- get(RpcController, ClientProtos.GetRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
Get data from a table.
- get(UriInfo) - Method in class org.apache.hadoop.hbase.rest.ExistsResource
- get(UriInfo) - Method in class org.apache.hadoop.hbase.rest.RegionsResource
- get(UriInfo) - Method in class org.apache.hadoop.hbase.rest.RootResource
- get(UriInfo) - Method in class org.apache.hadoop.hbase.rest.RowResource
- get(UriInfo) - Method in class org.apache.hadoop.hbase.rest.SchemaResource
- get(UriInfo) - Method in class org.apache.hadoop.hbase.rest.StorageClusterStatusResource
- get(UriInfo) - Method in class org.apache.hadoop.hbase.rest.StorageClusterVersionResource
- get(UriInfo) - Method in class org.apache.hadoop.hbase.rest.TableScanResource
- get(UriInfo, int, int) - Method in class org.apache.hadoop.hbase.rest.ScannerInstanceResource
- get(UriInfo, String, String, String) - Method in class org.apache.hadoop.hbase.rest.MultiRowResource
- get(TNode, Object, AvlUtil.AvlKeyComparator<TNode>) - Static method in class org.apache.hadoop.hbase.util.AvlUtil.AvlTree
-
Return the node that matches the specified key or null in case of node not found.
- org.apache.hadoop.hbase.client.Get - Class in org.apache.hadoop.hbase.client
-
Used to perform Get operations on a single row.
- Get(byte[]) - Constructor for class org.apache.hadoop.hbase.client.Get
-
Create a Get operation for the specified row.
- Get(byte[], int, int) - Constructor for class org.apache.hadoop.hbase.client.Get
-
Create a Get operation for the specified row.
- Get(ByteBuffer) - Constructor for class org.apache.hadoop.hbase.client.Get
-
Create a Get operation for the specified row.
- Get(Get) - Constructor for class org.apache.hadoop.hbase.client.Get
-
Copy-constructor
- GET - Enum constant in enum class org.apache.hadoop.hbase.quotas.OperationQuota.OperationType
- GET - Enum constant in enum class org.apache.hadoop.hbase.regionserver.Region.Operation
- GET_BLOCK_BYTES_SCANNED_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- GET_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- GET_SIZE_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- get25thPercentile() - Method in interface org.apache.hadoop.hbase.metrics.Snapshot
-
Returns the value at the 25th percentile in the distribution.
- get75thPercentile() - Method in class org.apache.hadoop.hbase.io.hfile.AgeSnapshot
- get75thPercentile() - Method in interface org.apache.hadoop.hbase.metrics.Snapshot
-
Returns the value at the 75th percentile in the distribution.
- get90thPercentile() - Method in interface org.apache.hadoop.hbase.metrics.Snapshot
-
Returns the value at the 90th percentile in the distribution.
- get95thPercentile() - Method in class org.apache.hadoop.hbase.io.hfile.AgeSnapshot
- get95thPercentile() - Method in interface org.apache.hadoop.hbase.metrics.Snapshot
-
Returns the value at the 95th percentile in the distribution.
- get98thPercentile() - Method in class org.apache.hadoop.hbase.io.hfile.AgeSnapshot
- get98thPercentile() - Method in interface org.apache.hadoop.hbase.metrics.Snapshot
-
Returns the value at the 98th percentile in the distribution.
- get999thPercentile() - Method in class org.apache.hadoop.hbase.io.hfile.AgeSnapshot
- get999thPercentile() - Method in interface org.apache.hadoop.hbase.metrics.Snapshot
-
Returns the value at the 99.9th percentile in the distribution.
- get99thPercentile() - Method in class org.apache.hadoop.hbase.io.hfile.AgeSnapshot
- get99thPercentile() - Method in interface org.apache.hadoop.hbase.metrics.Snapshot
-
Returns the value at the 99th percentile in the distribution.
- getAbortable() - Method in class org.apache.hadoop.hbase.replication.ReplicationEndpoint.Context
- getAcceptedIssuers() - Method in class org.apache.hadoop.hbase.io.crypto.tls.HBaseTrustManager
- getAccessChecker() - Method in class org.apache.hadoop.hbase.HBaseRpcServicesBase
- getAccessChecker() - Method in class org.apache.hadoop.hbase.HBaseServerBase
- getAccessChecker() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Returns the
AccessChecker
- getAccessChecker() - Method in class org.apache.hadoop.hbase.MockRegionServerServices
- getAccessChecker() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
Returns the
AccessChecker
- getAccessCount() - Method in class org.apache.hadoop.hbase.mob.MobFileCache
-
Gets the count of accesses to the mob file cache.
- getAcl(String, Stat) - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
getAcl is an idempotent operation.
- getACL() - Method in class org.apache.hadoop.hbase.client.ImmutableScan
- getACL() - Method in class org.apache.hadoop.hbase.client.Mutation
-
Returns The serialized ACL for this operation, or null if none
- getACL() - Method in class org.apache.hadoop.hbase.client.Query
-
Returns The serialized ACL for this operation, or null if none
- getAction() - Method in class org.apache.hadoop.hbase.client.Action
- getAction() - Method in class org.apache.hadoop.hbase.client.CheckAndMutate
-
Returns the action done if check succeeds
- getAction(VersionedSegmentsList) - Method in class org.apache.hadoop.hbase.regionserver.AdaptiveMemStoreCompactionStrategy
- getAction(VersionedSegmentsList) - Method in class org.apache.hadoop.hbase.regionserver.BasicMemStoreCompactionStrategy
- getAction(VersionedSegmentsList) - Method in class org.apache.hadoop.hbase.regionserver.EagerMemStoreCompactionStrategy
- getAction(VersionedSegmentsList) - Method in class org.apache.hadoop.hbase.regionserver.MemStoreCompactionStrategy
- getActiveBulkLoadRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.DelegatingRpcScheduler
- getActiveBulkLoadRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.FifoRpcScheduler
- getActiveBulkLoadRpcHandlerCount() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapper
- getActiveBulkLoadRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapperImpl
- getActiveBulkLoadRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.RpcScheduler
-
Retrieves the number of active bulkload handler.
- getActiveBulkLoadRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
- getActiveEnforcements() - Method in class org.apache.hadoop.hbase.quotas.RegionServerSpaceQuotaManager
-
Creates an object well-suited for the RegionServer to use in verifying active policies.
- getActiveFileName() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
Return the active file name that contains the real data.
- getActiveGeneralRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.DelegatingRpcScheduler
- getActiveGeneralRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.FifoRpcScheduler
- getActiveGeneralRpcHandlerCount() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapper
- getActiveGeneralRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapperImpl
- getActiveGeneralRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.RpcScheduler
-
Retrieves the number of active general handler.
- getActiveGeneralRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
- getActiveHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.RpcExecutor
- getActiveHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
- getActiveLogFiles() - Static method in class org.apache.hadoop.hbase.logging.Log4jUtils
- getActiveMaster() - Method in class org.apache.hadoop.hbase.client.MasterRegistry
- getActiveMaster() - Method in interface org.apache.hadoop.hbase.client.ConnectionRegistry
-
Get the address of active HMaster.
- getActiveMaster() - Method in interface org.apache.hadoop.hbase.client.ConnectionRegistryEndpoint
-
Get active master address.
- getActiveMaster() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
Gets the current active master, if available.
- getActiveMaster() - Method in class org.apache.hadoop.hbase.master.HMaster
- getActiveMaster() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
- getActiveMaster(RpcController, RegistryProtos.GetActiveMasterRequest) - Method in class org.apache.hadoop.hbase.HBaseRpcServicesBase
- getActiveMasterAddress() - Method in interface org.apache.hadoop.hbase.testing.TestingHBaseCluster
-
Get the address of active master if there is one.
- getActiveMasterInfoPort() - Method in class org.apache.hadoop.hbase.master.ActiveMasterManager
- getActiveMasterInfoPort() - Method in class org.apache.hadoop.hbase.master.HMaster
-
Returns info port of active master or 0 if any exception occurs.
- getActiveMasterManager() - Method in class org.apache.hadoop.hbase.master.HMaster
- getActiveMasterServerName() - Method in class org.apache.hadoop.hbase.master.ActiveMasterManager
- getActiveMetaPriorityRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.DelegatingRpcScheduler
- getActiveMetaPriorityRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.FifoRpcScheduler
- getActiveMetaPriorityRpcHandlerCount() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapper
- getActiveMetaPriorityRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapperImpl
- getActiveMetaPriorityRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.RpcScheduler
-
Retrieves the number of active meta priority handler.
- getActiveMetaPriorityRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
- getActivePoliciesAsMap() - Method in class org.apache.hadoop.hbase.quotas.RegionServerSpaceQuotaManager
-
Converts a map of table to
SpaceViolationPolicyEnforcement
s intoSpaceViolationPolicy
s. - getActivePriorityRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.DelegatingRpcScheduler
- getActivePriorityRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.FifoRpcScheduler
- getActivePriorityRpcHandlerCount() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapper
- getActivePriorityRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapperImpl
- getActivePriorityRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.RpcScheduler
-
Retrieves the number of active priority handler.
- getActivePriorityRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
- getActiveReadHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.RpcExecutor
- getActiveReadHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
- getActiveReadRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.DelegatingRpcScheduler
- getActiveReadRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.FifoRpcScheduler
- getActiveReadRpcHandlerCount() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapper
- getActiveReadRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapperImpl
- getActiveReadRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.RpcScheduler
-
Retrieves the number of active write rpc handler when use RWQueueRpcExecutor.
- getActiveReadRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
- getActiveReplicationRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.DelegatingRpcScheduler
- getActiveReplicationRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.FifoRpcScheduler
- getActiveReplicationRpcHandlerCount() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapper
- getActiveReplicationRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapperImpl
- getActiveReplicationRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.RpcScheduler
-
Retrieves the number of active replication handler.
- getActiveReplicationRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
- getActiveRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.DelegatingRpcScheduler
- getActiveRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.FifoRpcScheduler
- getActiveRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.MasterFifoRpcScheduler
- getActiveRpcHandlerCount() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapper
- getActiveRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapperImpl
- getActiveRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.RpcScheduler
-
Retrieves the total number of active handler.
- getActiveRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
- getActiveScanHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.RpcExecutor
- getActiveScanHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
- getActiveScanners() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
- getActiveScanRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.DelegatingRpcScheduler
- getActiveScanRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.FifoRpcScheduler
- getActiveScanRpcHandlerCount() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapper
- getActiveScanRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapperImpl
- getActiveScanRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.RpcScheduler
-
Retrieves the number of active write rpc handler when use RWQueueRpcExecutor.
- getActiveScanRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
- getActiveTime() - Method in interface org.apache.hadoop.hbase.master.MetricsMasterWrapper
-
Get the hbase master active time
- getActiveTime() - Method in class org.apache.hadoop.hbase.master.MetricsMasterWrapperImpl
- getActiveWriteHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.RpcExecutor
- getActiveWriteHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
- getActiveWriteRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.DelegatingRpcScheduler
- getActiveWriteRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.FifoRpcScheduler
- getActiveWriteRpcHandlerCount() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapper
- getActiveWriteRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapperImpl
- getActiveWriteRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.RpcScheduler
-
Retrieves the number of active write rpc handler when use RWQueueRpcExecutor.
- getActiveWriteRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
- getAdaptiveTimeout(int, int) - Static method in class org.apache.hadoop.hbase.replication.ReplicationUtils
-
Get the adaptive timeout value when performing a retry
- getAddress() - Method in class org.apache.hadoop.hbase.ServerName
- getAddress() - Method in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
-
Returns Address for this cluster instance.
- getAdmin() - Method in interface org.apache.hadoop.hbase.client.AsyncConnection
-
Retrieve an
AsyncAdmin
implementation to administer an HBase cluster. - getAdmin() - Method in interface org.apache.hadoop.hbase.client.Connection
-
Retrieve an Admin implementation to administer an HBase cluster.
- getAdmin() - Method in class org.apache.hadoop.hbase.client.SharedConnection
- getAdmin() - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Returns an Admin instance which is shared between HBaseTestingUtility instance users.
- getAdmin() - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
Allows subclasses to get the
Admin
. - getAdmin() - Method in class org.apache.hadoop.hbase.thrift.HBaseServiceHandler
-
Obtain HBaseAdmin.
- getAdmin() - Method in class org.apache.hadoop.hbase.util.ConnectionCache
-
Caller doesn't close the admin afterwards.
- getAdmin(ExecutorService) - Method in interface org.apache.hadoop.hbase.client.AsyncConnection
-
Retrieve an
AsyncAdmin
implementation to administer an HBase cluster. - getAdminBuilder() - Method in interface org.apache.hadoop.hbase.client.AsyncConnection
-
Returns an
AsyncAdminBuilder
for creatingAsyncAdmin
. - getAdminBuilder() - Method in class org.apache.hadoop.hbase.client.AsyncConnectionImpl
- getAdminBuilder() - Method in class org.apache.hadoop.hbase.client.SharedAsyncConnection
- getAdminBuilder(ExecutorService) - Method in interface org.apache.hadoop.hbase.client.AsyncConnection
-
Returns an
AsyncAdminBuilder
for creatingAsyncAdmin
. - getAdminBuilder(ExecutorService) - Method in class org.apache.hadoop.hbase.client.AsyncConnectionImpl
- getAdminBuilder(ExecutorService) - Method in class org.apache.hadoop.hbase.client.SharedAsyncConnection
- getAgeAtEvictionSnapshot() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
- getAgeInCacheSnapshot() - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil.CachedBlocksByFile
- getAgeOfLastAppliedOp() - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSink
- getAgeOfLastShippedOp() - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSource
- getAggregateRequestPerSecond() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.Summary
- getAggregateSource() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
-
Get the aggregate source to which this reports.
- getAggregateSource() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionSourceImpl
- getAggregateSource() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableSource
-
Get the aggregate source to which this reports.
- getAggregateSource() - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableSourceImpl
- getAliasPassword(String) - Method in class org.apache.hadoop.hbase.io.crypto.KeyStoreKeyProvider
- getAll() - Method in class org.apache.hadoop.hbase.master.MasterRegionServerList
- getAll() - Method in interface org.apache.hadoop.hbase.master.RegionServerList
-
Get all live region servers.
- getAll() - Method in interface org.apache.hadoop.hbase.TableDescriptors
-
Get Map of all TableDescriptors.
- getAll() - Method in class org.apache.hadoop.hbase.util.FSTableDescriptors
-
Returns a map from table name to table descriptor for all tables.
- getAll(List<Get>) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
A simple version for batch get.
- getAllBootstrapNodes(ServerName) - Method in interface org.apache.hadoop.hbase.client.AsyncClusterConnection
-
Get the bootstrap node list of another region server.
- getAllBootstrapNodes(RpcController, BootstrapNodeProtos.GetAllBootstrapNodesRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
- getAllCached() - Static method in class org.apache.hadoop.hbase.util.CoprocessorClassLoader
- getAllFilters() - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Returns all known filters
- getAllHFileRefs() - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueueStorage
-
Load all hfile references in all replication queues.
- getAllHFileRefs() - Method in class org.apache.hadoop.hbase.replication.TableReplicationQueueStorage
- getAllOnlineRegions(MiniHBaseCluster) - Static method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- getAllowPartialResults() - Method in class org.apache.hadoop.hbase.client.ImmutableScan
- getAllowPartialResults() - Method in class org.apache.hadoop.hbase.client.Scan
-
Returns true when the constructor of this scan understands that the results they will see may only represent a partial portion of a row.
- getAllPeerIds() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeers
-
Returns the set of peerIds of the clusters that have been connected and have an underlying ReplicationPeer.
- getAllPeersFromHFileRefsQueue() - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueueStorage
-
Get list of all peers from hfile reference queue.
- getAllPeersFromHFileRefsQueue() - Method in class org.apache.hadoop.hbase.replication.TableReplicationQueueStorage
- getAllRegionLocations() - Method in interface org.apache.hadoop.hbase.client.AsyncTableRegionLocator
-
Retrieves all of the regions associated with this table.
- getAllRegionLocations() - Method in interface org.apache.hadoop.hbase.client.RegionLocator
-
Retrieves all of the regions associated with this table.
- getAllRegions(Connection, boolean) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Lists all of the regions currently in META.
- getAllSegments() - Method in class org.apache.hadoop.hbase.regionserver.CompositeImmutableSegment
- getAllSegments() - Method in class org.apache.hadoop.hbase.regionserver.ImmutableSegment
- getAllWALProviders() - Method in class org.apache.hadoop.hbase.wal.WALFactory
-
Returns all the wal providers, for example, the default one, the one for hbase:meta and the one for hbase:replication.
- getAndCallByName(String, I) - Method in class org.apache.hadoop.hbase.util.ReflectedFunctionCache
-
Get and execute the Function for the given className, passing the argument to the function and returning the result.
- getAndResetChecksumFailuresCount() - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
-
Number of checksum verification failures.
- getAnnotatedPriority(RPCProtos.RequestHeader) - Method in class org.apache.hadoop.hbase.ipc.AnnotationReadingPriorityFunction
-
See if the method has an annotation.
- getAppendTracker() - Method in class org.apache.hadoop.hbase.client.MetricsConnection
-
appendTracker metric
- getArchivedStoreFilesCount() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
-
Returns the number of available store files in the archive
- getArchivedStoreFileSize() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
-
Returns the total size of the store files in the archive
- getArchivedWALFiles(Configuration, ServerName, String) - Static method in class org.apache.hadoop.hbase.wal.AbstractFSWALProvider
-
List all the old wal files for a dead region server.
- getArchivePath() - Method in class org.apache.hadoop.hbase.io.HFileLink
-
Returns the path of the archived hfile.
- getArchivePath(Configuration) - Static method in class org.apache.hadoop.hbase.util.HFileArchiveUtil
-
Get the full path to the archive directory on the configured
MasterFileSystem
- getArgumentsFromCommandLine(Configuration, String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.ExportUtils
- getAssignmentManager() - Method in class org.apache.hadoop.hbase.master.HMaster
- getAssignmentManager() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Returns Master's instance of the
AssignmentManager
- getAssignmentMap() - Method in class org.apache.hadoop.hbase.favored.FavoredNodesPlan
-
Return the mapping between each region to its favored region server list.
- getAssignMetrics() - Method in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
-
Returns
OperationMetrics
containing common metrics for assign region operation - getAssignMetrics() - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManagerSourceImpl
- getAssignProcMetrics() - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManager
-
Returns Set of common metrics for assign procedure
- getAsyncClusterConnection() - Method in class org.apache.hadoop.hbase.HBaseServerBase
- getAsyncClusterConnection() - Method in class org.apache.hadoop.hbase.MockRegionServerServices
- getAsyncClusterConnection() - Method in interface org.apache.hadoop.hbase.Server
-
Returns a reference to the servers' async cluster connection.
- getAsyncConnection() - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Get a shared AsyncClusterConnection to the cluster.
- getAsyncConnection() - Method in interface org.apache.hadoop.hbase.Server
-
Returns a reference to the servers' async connection.
- getAsyncConnection(User) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Get a assigned AsyncClusterConnection to the cluster.
- getAttemptingUser() - Method in class org.apache.hadoop.hbase.security.HBaseSaslRpcServer
- getAttemptTimes() - Method in class org.apache.hadoop.hbase.util.RetryCounter
- getAttribute(String) - Method in interface org.apache.hadoop.hbase.client.Attributes
-
Gets an attribute
- getAttribute(String) - Method in class org.apache.hadoop.hbase.client.ImmutableScan
- getAttribute(String) - Method in class org.apache.hadoop.hbase.client.OperationWithAttributes
- getAttribute(String) - Method in class org.apache.hadoop.hbase.http.HttpServer
-
Get the value in the webapp context.
- getAttributes() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.Cell
- getAttributeSize() - Method in class org.apache.hadoop.hbase.client.ImmutableScan
- getAttributeSize() - Method in class org.apache.hadoop.hbase.client.OperationWithAttributes
- getAttributesKeyColumnIndex() - Method in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
- getAttributesMap() - Method in interface org.apache.hadoop.hbase.client.Attributes
-
Gets all attributes
- getAttributesMap() - Method in class org.apache.hadoop.hbase.client.ImmutableScan
- getAttributesMap() - Method in class org.apache.hadoop.hbase.client.OperationWithAttributes
- getAuthChore(Configuration) - Static method in class org.apache.hadoop.hbase.AuthUtil
-
Deprecated.Deprecated since 2.2.0, this method will be
InterfaceAudience.Private
use only after 4.0.0. - getAuthorizationID() - Method in class org.apache.hadoop.hbase.security.HBaseSaslRpcServer
- getAuthorizations() - Method in class org.apache.hadoop.hbase.client.ImmutableScan
- getAuthorizations() - Method in class org.apache.hadoop.hbase.client.Query
-
Returns The authorizations this Query is associated with.
- getAuthRenewalChore(UserGroupInformation, Configuration) - Static method in class org.apache.hadoop.hbase.AuthUtil
-
Deprecated.Checks if security is enabled and if so, launches chore for refreshing kerberos ticket.
- getAvailable() - Method in class org.apache.hadoop.hbase.quotas.RateLimiter
- getAvailablePath(FileSystem) - Method in class org.apache.hadoop.hbase.io.FileLink
-
Returns the path of the first available link.
- getAvailableWorker(ServerName) - Method in class org.apache.hadoop.hbase.master.WorkerAssigner
- getAverageLoad() - Method in interface org.apache.hadoop.hbase.ClusterMetrics
-
Returns the average cluster load
- getAverageLoad() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.Summary
- getAverageLoad() - Method in class org.apache.hadoop.hbase.master.HMaster
-
Compute the average load across all region servers.
- getAverageLoad() - Method in interface org.apache.hadoop.hbase.master.MetricsMasterWrapper
-
Get Average Load
- getAverageLoad() - Method in class org.apache.hadoop.hbase.master.MetricsMasterWrapperImpl
- getAverageLoad() - Method in class org.apache.hadoop.hbase.master.ServerManager
-
Compute the average load across all region servers.
- getAverageRegionSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the average region size to this region server.
- getAverageTime() - Method in class org.apache.hadoop.hbase.util.ExponentialMovingAverage
- getAverageTime() - Method in class org.apache.hadoop.hbase.util.MovingAverage
-
Get average execution time of the measured method.
- getAverageTime() - Method in class org.apache.hadoop.hbase.util.SimpleMovingAverage
- getAverageTime() - Method in class org.apache.hadoop.hbase.util.WeightedMovingAverage
- getAverageTime() - Method in class org.apache.hadoop.hbase.util.WindowMovingAverage
- getAvgKeyLen() - Method in class org.apache.hadoop.hbase.io.hfile.HFileInfo
- getAvgRegionSize(String) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregate
-
Get the average region size for this table
- getAvgRegionSize(String) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImpl
- getAvgStoreFileAge() - Method in class org.apache.hadoop.hbase.regionserver.HStore
- getAvgStoreFileAge() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Returns Average age of store files hosted on this region server
- getAvgStoreFileAge() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
-
Returns Average age of store files under this region
- getAvgStoreFileAge() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
- getAvgStoreFileAge() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Returns Average age of store files in this store
- getAvgStoreFileAge(String) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregate
-
Returns Average age of store files for this table
- getAvgStoreFileAge(String) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImpl
- getAvgValueLen() - Method in class org.apache.hadoop.hbase.io.hfile.HFileInfo
- getBackgroundColor() - Method in class org.apache.hadoop.hbase.hbtop.terminal.Attributes
- getBackgroundColor() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.Cell
- getBackoffPolicy() - Method in class org.apache.hadoop.hbase.util.RetryCounter.RetryConfig
- getBackoffTime() - Method in class org.apache.hadoop.hbase.util.RetryCounter
- getBackoffTime(ServerName, byte[], ServerStatistics) - Method in interface org.apache.hadoop.hbase.client.backoff.ClientBackoffPolicy
-
Returns the number of ms to wait on the client based on the
- getBackoffTime(ServerName, byte[], ServerStatistics) - Method in class org.apache.hadoop.hbase.client.backoff.ClientBackoffPolicyFactory.NoBackoffPolicy
- getBackoffTime(ServerName, byte[], ServerStatistics) - Method in class org.apache.hadoop.hbase.client.backoff.ExponentialClientBackoffPolicy
- getBackoffTime(RetryCounter.RetryConfig, int) - Method in class org.apache.hadoop.hbase.util.RetryCounter.BackoffPolicy
- getBackoffTime(RetryCounter.RetryConfig, int) - Method in class org.apache.hadoop.hbase.util.RetryCounter.ExponentialBackoffPolicy
- getBackoffTime(RetryCounter.RetryConfig, int) - Method in class org.apache.hadoop.hbase.util.RetryCounter.ExponentialBackoffPolicyWithLimit
- getBackoffTimeAndIncrementAttempts() - Method in class org.apache.hadoop.hbase.util.RetryCounter
- getBackReferenceFileName(Path) - Static method in class org.apache.hadoop.hbase.io.FileLink
-
Get the referenced file name from the reference link directory path.
- getBackReferencesDir(Path, String) - Static method in class org.apache.hadoop.hbase.io.FileLink
-
Get the directory to store the link back references
- getBackupCopyJob(Configuration) - Static method in class org.apache.hadoop.hbase.backup.BackupRestoreFactory
-
Gets backup copy job
- getBackupId() - Method in class org.apache.hadoop.hbase.backup.BackupInfo
- getBackupId() - Method in class org.apache.hadoop.hbase.backup.RestoreRequest
- getBackupInfo(String) - Method in interface org.apache.hadoop.hbase.backup.BackupAdmin
-
Describe backup image command
- getBackupMasterAddresses() - Method in interface org.apache.hadoop.hbase.testing.TestingHBaseCluster
-
Get all the backup master addresses.
- getBackupMasterInfoPort(ServerName) - Method in class org.apache.hadoop.hbase.master.ActiveMasterManager
- getBackupMasterInfoPort(ServerName) - Method in class org.apache.hadoop.hbase.master.HMaster
- getBackupMasterInfoPort(ServerName) - Method in class org.apache.hadoop.hbase.zookeeper.MasterAddressTracker
-
Get the info port of the backup master if it is available.
- getBackupMasterInfoPort(ZKWatcher, ServerName) - Static method in class org.apache.hadoop.hbase.zookeeper.MasterAddressTracker
-
Get backup master info port.
- getBackupMasterNames() - Method in interface org.apache.hadoop.hbase.ClusterMetrics
-
Returns the names of backup masters
- getBackupMasters() - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get a list of current backup masters.
- getBackupMasters() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Returns current backup master list wrapped by
CompletableFuture
- getBackupMasters() - Method in interface org.apache.hadoop.hbase.client.ConnectionRegistryEndpoint
-
Get backup masters address.
- getBackupMasters() - Method in class org.apache.hadoop.hbase.master.ActiveMasterManager
-
Returns list of registered backup masters.
- getBackupMasters() - Method in class org.apache.hadoop.hbase.master.HMaster
- getBackupMasters() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
- getBackupMasters() - Method in class org.apache.hadoop.hbase.zookeeper.MasterAddressTracker
- getBackupMastersAndRenewWatch(ZKWatcher) - Static method in class org.apache.hadoop.hbase.zookeeper.MasterAddressTracker
-
Retrieves the list of registered backup masters and renews a watch on the znode for children updates.
- getBackupMergeJob(Configuration) - Static method in class org.apache.hadoop.hbase.backup.BackupRestoreFactory
-
Gets backup merge job
- getBackupPath(String, String) - Static method in class org.apache.hadoop.hbase.backup.HBackupFileSystem
- getBackupRootDir() - Method in class org.apache.hadoop.hbase.backup.BackupInfo
- getBackupRootDir() - Method in class org.apache.hadoop.hbase.backup.RestoreRequest
- getBackupSet(String) - Method in interface org.apache.hadoop.hbase.backup.BackupAdmin
-
Backup set describe command.
- getBackupSetName() - Method in class org.apache.hadoop.hbase.backup.BackupRequest
- getBackupTableInfo(TableName) - Method in class org.apache.hadoop.hbase.backup.BackupInfo
- getBackupTmpDirPath(String) - Static method in class org.apache.hadoop.hbase.backup.HBackupFileSystem
-
Get backup temporary directory
- getBackupTmpDirPathForBackupId(String, String) - Static method in class org.apache.hadoop.hbase.backup.HBackupFileSystem
-
Get backup tmp directory for backupId
- getBackupType() - Method in class org.apache.hadoop.hbase.backup.BackupRequest
- getBackupZooKeeperServerNum() - Method in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
- getBadLineCount() - Method in class org.apache.hadoop.hbase.mapreduce.TextSortReducer
- getBadLineCount() - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
- getBadLineCount() - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterTextMapper
- getBalancer(String, Configuration, List<BlockingQueue<CallRunner>>) - Static method in class org.apache.hadoop.hbase.ipc.RpcExecutor
- getBalancerDecision() - Method in class org.apache.hadoop.hbase.namequeues.BalancerDecisionDetails
- getBalancerDecisionEntries(MasterProtos.BalancerDecisionsResponse) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
- getBalancerDecisions() - Method in class org.apache.hadoop.hbase.namequeues.response.NamedQueueGetResponse
- getBalancerDecisionsRequest() - Method in class org.apache.hadoop.hbase.namequeues.request.NamedQueueGetRequest
- getBalancerOn() - Method in interface org.apache.hadoop.hbase.ClusterMetrics
- getBalancerRejection() - Method in class org.apache.hadoop.hbase.namequeues.BalancerRejectionDetails
- getBalancerRejectionEntries(MasterProtos.BalancerRejectionsResponse) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
- getBalancerRejections() - Method in class org.apache.hadoop.hbase.namequeues.response.NamedQueueGetResponse
- getBalancerRejectionsRequest() - Method in class org.apache.hadoop.hbase.namequeues.request.NamedQueueGetRequest
- getBandwidth() - Method in class org.apache.hadoop.hbase.backup.BackupInfo
- getBandwidth() - Method in class org.apache.hadoop.hbase.backup.BackupRequest
- getBandwidth() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
- getBarriers() - Method in class org.apache.hadoop.hbase.replication.ReplicationBarrierFamilyFormat.ReplicationBarrierResult
- getBasePriority(RPCProtos.RequestHeader, Message) - Method in class org.apache.hadoop.hbase.ipc.AnnotationReadingPriorityFunction
-
Get the priority for a given request from the header and the param.
- getBasePriority(RPCProtos.RequestHeader, Message) - Method in class org.apache.hadoop.hbase.master.MasterAnnotationReadingPriorityFunction
- getBatch() - Method in class org.apache.hadoop.hbase.client.ImmutableScan
- getBatch() - Method in class org.apache.hadoop.hbase.client.Scan
-
Returns maximum number of values to return for a single call to next()
- getBatch() - Method in interface org.apache.hadoop.hbase.regionserver.RegionScanner
- getBestLocations(Configuration, HDFSBlocksDistribution) - Static method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl
- getBinary(UriInfo) - Method in class org.apache.hadoop.hbase.rest.RowResource
- getBinary(UriInfo) - Method in class org.apache.hadoop.hbase.rest.ScannerInstanceResource
- getBindAddress(Configuration) - Method in class org.apache.hadoop.hbase.thrift.ThriftServer
- getBlock(BlockCacheKey, boolean, boolean, boolean) - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCache
-
Fetch block from cache.
- getBlock(BlockCacheKey, boolean, boolean, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
- getBlock(BlockCacheKey, boolean, boolean, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.InclusiveCombinedBlockCache
- getBlock(BlockCacheKey, boolean, boolean, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache
-
Get the buffer of the block with the specified name.
- getBlock(BlockCacheKey, boolean, boolean, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
Get the buffer of the block with the specified name.
- getBlock(BlockCacheKey, boolean, boolean, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
- getBlock(BlockCacheKey, boolean, boolean, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.TinyLfuBlockCache
- getBlock(BlockCacheKey, boolean, boolean, boolean, BlockType) - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCache
-
Fetch block from cache.
- getBlock(BlockCacheKey, boolean, boolean, boolean, BlockType) - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
- getBlockBytesScanned() - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord
-
Return the amount of block bytes scanned to retrieve the response cells.
- getBlockBytesScanned() - Method in interface org.apache.hadoop.hbase.ipc.RpcCallContext
-
Get the number of block bytes scanned by the current call.
- getBlockBytesScanned() - Method in class org.apache.hadoop.hbase.ipc.ServerCall
- getBlockBytesScanned() - Method in class org.apache.hadoop.hbase.namequeues.RpcLogDetails
- getBlockCache() - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
Returns the block cache.
- getBlockCache() - Method in class org.apache.hadoop.hbase.MockRegionServerServices
- getBlockCache() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
- getBlockCache() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
May be null if this is a master which not carry table.
- getBlockCache() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
Returns The block cache instance.
- getBlockCacheCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the number of items in the block cache.
- getBlockCacheDataBlockCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the number of DATA blocks in the block cache.
- getBlockCacheEvictedCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the number of items evicted from the block cache.
- getBlockCacheFailedInsertions() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Number of cache insertions that failed.
- getBlockCacheFreeSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the size (in bytes) of the block cache that is free.
- getBlockCacheHeapPercent(Configuration) - Static method in class org.apache.hadoop.hbase.io.util.MemorySizeUtil
-
Retrieve configured size for on heap block cache as percentage of total heap.
- getBlockCacheHitCachingCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the count of hits to the block cache, for cacheable requests only.
- getBlockCacheHitCachingPercent() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the percent of requests with the block cache turned on that hit the block cache.
- getBlockCacheHitCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the count of hits to the block cache
- getBlockCacheHitPercent() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the percent of all requests that hit the block cache.
- getBlockCacheMissCachingCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the count of misses to the block cache, for cacheable requests only.
- getBlockCacheMissCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the count of misses to the block cache.
- getBlockCachePrimaryEvictedCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the number of items evicted from primary replica in the block cache.
- getBlockCachePrimaryHitCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the count of hits to primary replica in the block cache
- getBlockCachePrimaryMissCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the count of misses to primary replica in the block cache.
- getBlockCaches() - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCache
-
Returns The list of sub blockcaches that make up this one; returns null if no sub caches.
- getBlockCaches() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
- getBlockCaches() - Method in class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache
- getBlockCaches() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
- getBlockCaches() - Method in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
- getBlockCaches() - Method in class org.apache.hadoop.hbase.io.hfile.TinyLfuBlockCache
- getBlockCacheSize() - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerResult
- getBlockCacheSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the total size (in bytes) of the block cache.
- getBlockCount() - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCache
-
Returns the number of blocks currently cached in the block cache.
- getBlockCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
- getBlockCount() - Method in class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache
- getBlockCount() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
- getBlockCount() - Method in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
- getBlockCount() - Method in class org.apache.hadoop.hbase.io.hfile.TinyLfuBlockCache
- getBlockedFlushCount() - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerContext
- getBlockedRequestsCount() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
- getBlockedRequestsCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Returns Count of requests blocked because the memstore size is larger than blockingMemStoreSize
- getBlockedRequestsCount() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Returns the number of blocked requests
- getBlockForCaching(CacheConfig, HFileBlock) - Static method in class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil
-
Similarly to HFileBlock.Writer.getBlockForCaching(), creates a HFileBlock instance without checksum for caching.
- getBlockingFileCount() - Method in class org.apache.hadoop.hbase.regionserver.HStore
- getBlockingFileCount() - Method in interface org.apache.hadoop.hbase.regionserver.StoreConfigInformation
-
The number of files required before flushes for this store will be blocked.
- getBlockingService() - Method in class org.apache.hadoop.hbase.ipc.RpcServer.BlockingServiceAndInterface
- getBlockKey(int) - Method in interface org.apache.hadoop.hbase.io.hfile.BlockIndexChunk
- getBlockKeys() - Method in interface org.apache.hadoop.hbase.io.hfile.BlockIndexChunk
- getBlockLocalityIndex(String) - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution
-
Get the block locality index for a given host
- getBlockLocalityIndexForSsd(String) - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution
-
Get the block locality index for a ssd for a given host
- getBlockOffset(int) - Method in interface org.apache.hadoop.hbase.io.hfile.BlockIndexChunk
- getBlockPriority() - Method in interface org.apache.hadoop.hbase.io.hfile.CachedBlock
- getBlocksize() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Returns The storefile/hfile blocksize for this column family.
- getBlocksize() - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
- getBlockSize() - Method in class org.apache.hadoop.hbase.io.crypto.aes.AESDecryptor
- getBlockSize() - Method in class org.apache.hadoop.hbase.io.crypto.aes.AESEncryptor
- getBlockSize() - Method in class org.apache.hadoop.hbase.io.crypto.aes.CommonsCryptoAESDecryptor
- getBlockSize() - Method in class org.apache.hadoop.hbase.io.crypto.aes.CommonsCryptoAESEncryptor
- getBlockSize() - Method in interface org.apache.hadoop.hbase.io.crypto.Decryptor
-
Get the cipher's internal block size
- getBlockSize() - Method in interface org.apache.hadoop.hbase.io.crypto.Encryptor
-
Get the cipher's internal block size
- getBlockSize() - Method in class org.apache.hadoop.hbase.regionserver.StoreContext
- getBlockSize(BlockCacheKey) - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCache
-
Returns an Optional containing the size of the block related to the passed key.
- getBlockSize(BlockCacheKey) - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
- getBlocksLocalWeight() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
Returns the data at local weight of this region in the regionserver
- getBlocksLocalWeight(String) - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution
-
Get the blocks local weight for a given host
- getBlocksLocalWithSsdWeight() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
Different from blocksLocalWeight,this metric's numerator only include the data stored on ssd
- getBlocksLocalWithSsdWeight(String) - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution
-
Get the blocks local weight with ssd for a given host
- getBlocksTotalWeight() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
Returns the block total weight of this region
- getBlockType() - Method in class org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultEncodingContext
- getBlockType() - Method in interface org.apache.hadoop.hbase.io.encoding.HFileBlockEncodingContext
-
Returns the block type after encoding
- getBlockType() - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheKey
- getBlockType() - Method in interface org.apache.hadoop.hbase.io.hfile.Cacheable
-
Returns the block type of this cached HFile block
- getBlockType() - Method in interface org.apache.hadoop.hbase.io.hfile.CachedBlock
- getBlockType() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
- getBloomBlockCount() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
- getBloomBlockSize(Configuration) - Static method in class org.apache.hadoop.hbase.util.BloomFilterFactory
-
Returns the compound Bloom filter block size from the configuration
- getBloomChunkHitCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
- getBloomChunkHitCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
- getBloomChunkHitCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
- getBloomChunkMissCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
- getBloomChunkMissCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
- getBloomChunkMissCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
- getBloomFilterEligibleRequestsCount() - Method in class org.apache.hadoop.hbase.regionserver.HStore
- getBloomFilterEligibleRequestsCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Count of requests which could have used bloom filters, but they weren't configured or loaded.
- getBloomFilterEligibleRequestsCount() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Returns count of requests which could have used bloom filters, but they weren't configured or loaded.
- getBloomFilterEligibleRequestsCount(String) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregate
-
Returns count of requests which could have used bloom filters for this table, but they weren't configured or loaded.
- getBloomFilterEligibleRequestsCount(String) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImpl
- getBloomFilterMetrics() - Method in class org.apache.hadoop.hbase.regionserver.StoreEngine
- getBloomFilterNegativeResultsCount() - Method in class org.apache.hadoop.hbase.regionserver.HStore
- getBloomFilterNegativeResultsCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Count of bloom filter requests which return a negative result.
- getBloomFilterNegativeResultsCount() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Returns count of negative results for bloom filter requests for this store.
- getBloomFilterNegativeResultsCount(String) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregate
-
Returns count of bloom filter requests which return a negative result for this table.
- getBloomFilterNegativeResultsCount(String) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImpl
- getBloomFilterParam(BloomType, Configuration) - Static method in class org.apache.hadoop.hbase.util.BloomFilterUtil
- getBloomFilterRequestsCount() - Method in class org.apache.hadoop.hbase.regionserver.HStore
- getBloomFilterRequestsCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Count of bloom filter requests.
- getBloomFilterRequestsCount() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Returns count of bloom filter results for this store.
- getBloomFilterRequestsCount(String) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregate
-
Returns count of bloom filter requests for this table.
- getBloomFilterRequestsCount(String) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImpl
- getBloomFilterSize() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
Returns The total size of all Bloom filter blocks, not just loaded into the block cache
- getBloomFilterType() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Returns bloom filter type used for new StoreFiles in ColumnFamily
- getBloomFilterType() - Method in class org.apache.hadoop.hbase.regionserver.StoreContext
- getBloomFilterType() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileReader
- getBody() - Method in class org.apache.hadoop.hbase.rest.client.Response
-
Returns the HTTP response body
- getBoolean(String, boolean) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
- getBootstrapNodes() - Method in interface org.apache.hadoop.hbase.client.ConnectionRegistryEndpoint
-
Get a iterator of the available bootstrap nodes.
- getBootstrapNodes() - Method in class org.apache.hadoop.hbase.master.HMaster
- getBootstrapNodes() - Method in class org.apache.hadoop.hbase.regionserver.BootstrapNodeManager
- getBootstrapNodes() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
- getBootstrapNodes(Configuration) - Method in class org.apache.hadoop.hbase.client.MasterRegistry
-
Deprecated.
- getBootstrapNodes(Configuration) - Method in class org.apache.hadoop.hbase.client.RpcConnectionRegistry
- getBootstrapNodes(RpcController, RegistryProtos.GetBootstrapNodesRequest) - Method in class org.apache.hadoop.hbase.HBaseRpcServicesBase
- getBoundedCachedThreadPool(int, long, TimeUnit, ThreadFactory) - Static method in class org.apache.hadoop.hbase.util.Threads
-
Create a new CachedThreadPool with a bounded number as the maximum thread size in the pool.
- getBrokenStoreFileCleaner() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
- getBucketCacheSize(Configuration) - Static method in class org.apache.hadoop.hbase.io.util.MemorySizeUtil
- getBucketCacheStats() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
- getBucketSize() - Method in class org.apache.hadoop.hbase.util.LossyCounting
- getBuffer() - Method in class org.apache.hadoop.hbase.ByteBufferKeyValue
- getBuffer() - Method in class org.apache.hadoop.hbase.io.ByteArrayOutputStream
-
Returns the underlying array where the data gets accumulated
- getBuffer() - Method in class org.apache.hadoop.hbase.io.hfile.LruCachedBlock
- getBuffer() - Method in class org.apache.hadoop.hbase.KeyValue
-
To be used only in tests where the Cells are clearly assumed to be of type KeyValue and that we need access to the backing array to do some test case related assertions.
- getBufferedMutator(BufferedMutatorParams) - Method in interface org.apache.hadoop.hbase.client.Connection
-
Retrieve a
BufferedMutator
for performing client-side buffering of writes. - getBufferedMutator(BufferedMutatorParams) - Method in class org.apache.hadoop.hbase.client.SharedConnection
- getBufferedMutator(TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncConnection
-
Retrieve an
AsyncBufferedMutator
for performing client-side buffering of writes. - getBufferedMutator(TableName) - Method in interface org.apache.hadoop.hbase.client.Connection
-
Retrieve a
BufferedMutator
for performing client-side buffering of writes. - getBufferedMutator(TableName) - Method in class org.apache.hadoop.hbase.client.SharedConnection
- getBufferedMutator(TableName, ExecutorService) - Method in interface org.apache.hadoop.hbase.client.AsyncConnection
-
Retrieve an
AsyncBufferedMutator
for performing client-side buffering of writes. - getBufferedMutatorBuilder(TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncConnection
-
Returns an
AsyncBufferedMutatorBuilder
for creatingAsyncBufferedMutator
. - getBufferedMutatorBuilder(TableName) - Method in class org.apache.hadoop.hbase.client.AsyncConnectionImpl
- getBufferedMutatorBuilder(TableName) - Method in class org.apache.hadoop.hbase.client.SharedAsyncConnection
- getBufferedMutatorBuilder(TableName, ExecutorService) - Method in interface org.apache.hadoop.hbase.client.AsyncConnection
-
Returns an
AsyncBufferedMutatorBuilder
for creatingAsyncBufferedMutator
. - getBufferedMutatorBuilder(TableName, ExecutorService) - Method in class org.apache.hadoop.hbase.client.AsyncConnectionImpl
- getBufferedMutatorBuilder(TableName, ExecutorService) - Method in class org.apache.hadoop.hbase.client.SharedAsyncConnection
- getBufferReadOnly() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
Returns a read-only duplicate of the buffer this block stores internally ready to be read.
- getBufferSize() - Method in class org.apache.hadoop.hbase.io.ByteBuffAllocator
- getBufferWithoutHeader() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
Returns a buffer that does not include the header and checksum.
- getBuilder() - Static method in class org.apache.hadoop.hbase.regionserver.StoreContext
- getBuilder(WALCellCodec.ByteStringCompressor) - Method in class org.apache.hadoop.hbase.wal.WALKeyImpl
- getBuilder(ServerName, byte[], ServerName, long) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
- getBulkLoadDescriptor(Cell) - Static method in class org.apache.hadoop.hbase.wal.WALEdit
-
Deserialized and returns a BulkLoadDescriptor from the passed in Cell
- getBulkLoadObserver() - Method in interface org.apache.hadoop.hbase.coprocessor.RegionCoprocessor
- getBulkLoadQueueLength() - Method in class org.apache.hadoop.hbase.ipc.DelegatingRpcScheduler
- getBulkLoadQueueLength() - Method in class org.apache.hadoop.hbase.ipc.FifoRpcScheduler
- getBulkLoadQueueLength() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapper
- getBulkLoadQueueLength() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapperImpl
- getBulkLoadQueueLength() - Method in class org.apache.hadoop.hbase.ipc.RpcScheduler
-
Retrieves length of the bulkload queue for metrics.
- getBulkLoadQueueLength() - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
- getBulkloadSeqId(Path) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
- getBulkLoadTimestamp() - Method in class org.apache.hadoop.hbase.regionserver.HStoreFile
- getBulkLoadTimestamp() - Method in interface org.apache.hadoop.hbase.regionserver.StoreFile
-
Return the timestamp at which this bulk load file was generated.
- getByNamespace(String) - Method in interface org.apache.hadoop.hbase.TableDescriptors
-
Get Map of all NamespaceDescriptors for a given namespace.
- getByNamespace(String) - Method in class org.apache.hadoop.hbase.util.FSTableDescriptors
-
Find descriptors by namespace.
- getBypassGlobals() - Method in class org.apache.hadoop.hbase.quotas.GlobalQuotaSettingsImpl
- getByteAfterPosition(int) - Method in class org.apache.hadoop.hbase.nio.ByteBuff
-
Fetches the byte at the given offset from current position.
- getByteAfterPosition(int) - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
- getByteAfterPosition(int) - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
- getByteBuffAllocator() - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
- getByteBuffAllocator() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
- getByteBuffAllocator() - Method in class org.apache.hadoop.hbase.ipc.RpcServer
- getByteBuffAllocator() - Method in interface org.apache.hadoop.hbase.ipc.RpcServerInterface
-
Allocator to allocate/free the ByteBuffers, those ByteBuffers can be on-heap or off-heap.
- getByteBuffAllocator() - Method in class org.apache.hadoop.hbase.regionserver.RegionServicesForStores
- getByteBuffAllocatorHeapAllocationBytes() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
- getByteBuffAllocatorHeapAllocRatio() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
- getByteBuffAllocatorPoolAllocationBytes() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
- getByteBuffAllocatorTotalBufferCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
- getByteBuffAllocatorUsedBufferCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
- getByteBuffer() - Method in class org.apache.hadoop.hbase.io.ByteBufferListOutputStream
- getByteBuffer() - Method in class org.apache.hadoop.hbase.io.ByteBufferOutputStream
-
This flips the underlying BB so be sure to use it _last_!
- getByteBuffers() - Method in class org.apache.hadoop.hbase.io.ByteBufferListOutputStream
-
We can be assured that the buffers returned by this method are all flipped
- getBytes() - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
- getBytes() - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
The underlying byte[].
- getBytes() - Method in class org.apache.hadoop.hbase.util.HashedBytes
- getBytes(ByteBuffer) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Returns a new byte array, copied from the given
buf
, from the position (inclusive) to the limit (exclusive). - getBytes(Writable) - Static method in class org.apache.hadoop.hbase.util.Writables
-
Get the Writable's contents as a byte array
- getBytes(Writable...) - Static method in class org.apache.hadoop.hbase.util.Writables
-
Put a bunch of Writables as bytes all into the one byte array.
- getByteSize() - Method in class org.apache.hadoop.hbase.io.hfile.CompoundBloomFilterBase
- getByteSize() - Method in interface org.apache.hadoop.hbase.util.BloomFilterBase
-
Returns Size of the bloom, in bytes
- getByteSize() - Method in class org.apache.hadoop.hbase.util.BloomFilterChunk
- getBytesPerChecksum() - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
- getBytesPerChecksum(Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.StoreUtils
-
Returns the configured bytesPerChecksum value.
- getBytesPerSec() - Method in class org.apache.hadoop.hbase.io.hadoopbackport.ThrottledInputStream
-
Getter for the read-rate from this stream, since creation.
- getByteStringCompressor() - Method in class org.apache.hadoop.hbase.regionserver.wal.WALCellCodec
- getByteStringUncompressor() - Method in class org.apache.hadoop.hbase.regionserver.wal.WALCellCodec
- getCacheBlocks() - Method in class org.apache.hadoop.hbase.client.Get
-
Get whether blocks should be cached for this Get.
- getCacheBlocks() - Method in class org.apache.hadoop.hbase.client.ImmutableScan
- getCacheBlocks() - Method in class org.apache.hadoop.hbase.client.Scan
-
Get whether blocks should be cached for this Scan.
- getCacheCompactedBlocksOnWriteThreshold() - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
Returns total file size in bytes threshold for caching while writing during compaction
- getCacheConf() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
- getCacheConf() - Method in class org.apache.hadoop.hbase.regionserver.HStoreFile
- getCacheConf() - Method in class org.apache.hadoop.hbase.regionserver.StoreContext
- getCacheConfig() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
Used for tests.
- getCacheDataBlockPercent() - Method in class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache
- getCachedBlockStatsByFile() - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil.CachedBlocksByFile
- getCachedFilesList(ServerName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get the list of cached files
- getCachedFilesList(ServerName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Get the list of cached files
- getCachedFilesList(RpcController, AdminProtos.AdminService.BlockingInterface) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Get the list of cached files
- getCachedFilesList(RpcController, AdminProtos.GetCachedFilesListRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- getCachedFilesList(RpcController, AdminProtos.GetCachedFilesListRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
- getCachedTime() - Method in interface org.apache.hadoop.hbase.io.hfile.CachedBlock
- getCachedTime() - Method in class org.apache.hadoop.hbase.io.hfile.LruCachedBlock
-
Returns Time we were cached at in nano seconds.
- getCacheKey() - Method in class org.apache.hadoop.hbase.io.hfile.LruCachedBlock
- getCacheMissCount() - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerContext
- getCacheOnWrite() - Method in class org.apache.hadoop.hbase.io.hfile.CompoundBloomFilterWriter
- getCacheOnWrite() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexWriter
- getCacheOnWrite() - Method in interface org.apache.hadoop.hbase.io.hfile.InlineBlockWriter
-
Returns true if inline blocks produced by this writer should be cached
- getCacheSize() - Method in class org.apache.hadoop.hbase.mob.MobFileCache
-
Gets the count of cached mob files.
- getCacheSize() - Method in class org.apache.hadoop.hbase.quotas.FileArchiverNotifierFactoryImpl
- getCacheStats() - Method in class org.apache.hadoop.hbase.master.CachedClusterId
- getCaching() - Method in class org.apache.hadoop.hbase.client.ImmutableScan
- getCaching() - Method in class org.apache.hadoop.hbase.client.Scan
-
Returns caching the number of rows fetched when calling next on a scanner
- getCallDetails() - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord
- getCalledMethodNames(String) - Method in class org.apache.hadoop.hbase.ipc.CallQueueInfo
- getCaller() - Method in interface org.apache.hadoop.hbase.coprocessor.ObserverContext
-
Returns the active user for the coprocessor call.
- getCaller() - Method in class org.apache.hadoop.hbase.coprocessor.ObserverContextImpl
- getCallMethod(CallRunner) - Method in class org.apache.hadoop.hbase.ipc.FifoRpcScheduler
- getCallMethodCount(String, String) - Method in class org.apache.hadoop.hbase.ipc.CallQueueInfo
- getCallMethodSize(String, String) - Method in class org.apache.hadoop.hbase.ipc.CallQueueInfo
- getCallQueueCountsSummary() - Method in class org.apache.hadoop.hbase.ipc.RpcExecutor
- getCallQueueInfo() - Method in class org.apache.hadoop.hbase.ipc.DelegatingRpcScheduler
- getCallQueueInfo() - Method in class org.apache.hadoop.hbase.ipc.FifoRpcScheduler
- getCallQueueInfo() - Method in class org.apache.hadoop.hbase.ipc.MasterFifoRpcScheduler
- getCallQueueInfo() - Method in class org.apache.hadoop.hbase.ipc.RpcScheduler
-
Get call queue information
- getCallQueueInfo() - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
- getCallQueueNames() - Method in class org.apache.hadoop.hbase.ipc.CallQueueInfo
- getCallQueueSizeSummary() - Method in class org.apache.hadoop.hbase.ipc.RpcExecutor
- getCallRunner() - Method in class org.apache.hadoop.hbase.ipc.FastPathRpcHandler
- getCallRunner() - Method in class org.apache.hadoop.hbase.ipc.RpcHandler
-
Returns A
CallRunner
n - getCallTimeMs() - Method in class org.apache.hadoop.hbase.client.MetricsConnection.CallStats
- getCallTimeout() - Method in class org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
- getCallTimeout() - Method in interface org.apache.hadoop.hbase.ipc.HBaseRpcController
- getCallTimeout() - Method in class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
- getCandidateFilesForRowKeyBefore(KeyValue) - Method in interface org.apache.hadoop.hbase.regionserver.StoreFileManager
-
Gets initial, full list of candidate store files to check for row-key-before.
- getCandidateFilesForRowKeyBefore(KeyValue) - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
-
See
StoreFileManager.getCandidateFilesForRowKeyBefore(KeyValue)
for details on this methods. - getCatalogFamilyRow(Connection, RegionInfo) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Returns Return the
HConstants.CATALOG_FAMILY
row from hbase:meta. - getCatalogJanitor() - Method in class org.apache.hadoop.hbase.master.HMaster
- getCatalogJanitor() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Returns Master's instance of
CatalogJanitor
- getCategory() - Method in enum class org.apache.hadoop.hbase.io.hfile.BlockType
- getCause() - Method in exception org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler.IOErrorWithCause
- getCause(int) - Method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
- getCauses() - Method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
- getCell() - Method in interface org.apache.hadoop.hbase.io.encoding.DataBlockEncoder.EncodedSeeker
-
Returns the Cell at the current position.
- getCell() - Method in class org.apache.hadoop.hbase.io.encoding.RowIndexSeekerV1
- getCell() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.EncodedScanner
- getCell() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
- getCell() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
-
Returns Instance of
ExtendedCell
. - getCell() - Method in class org.apache.hadoop.hbase.mob.MobCell
- getCell(int) - Method in class org.apache.hadoop.hbase.regionserver.CellArrayMap
- getCell(int) - Method in class org.apache.hadoop.hbase.regionserver.CellChunkMap
- getCell(int) - Method in class org.apache.hadoop.hbase.regionserver.CellFlatMap
- getCellBuilder() - Method in class org.apache.hadoop.hbase.client.Mutation
-
get a CellBuilder instance that already has relevant Type and Row set.
- getCellBuilder() - Method in interface org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment
-
Returns a CellBuilder so that coprocessors can build cells.
- getCellBuilder(CellBuilderType) - Method in class org.apache.hadoop.hbase.client.Append
- getCellBuilder(CellBuilderType) - Method in class org.apache.hadoop.hbase.client.Delete
- getCellBuilder(CellBuilderType) - Method in class org.apache.hadoop.hbase.client.Increment
- getCellBuilder(CellBuilderType) - Method in class org.apache.hadoop.hbase.client.Mutation
-
get a CellBuilder instance that already has relevant Type and Row set.
- getCellBuilder(CellBuilderType) - Method in class org.apache.hadoop.hbase.client.Put
- getCellBuilder(CellBuilderType, Cell.Type) - Method in class org.apache.hadoop.hbase.client.Mutation
-
get a CellBuilder instance that already has relevant Type and Row set.
- getCellCodecInputStream(FSDataInputStream) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractProtobufWALReader
-
Get or create the input stream used by cell decoder.
- getCellCodecInputStream(FSDataInputStream) - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufWALStreamReader
- getCellCodecInputStream(FSDataInputStream) - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufWALTailingReader
- getCellComparator() - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
- getCellComparator() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
- getCellComparator() - Method in interface org.apache.hadoop.hbase.regionserver.querymatcher.DeleteTracker
-
Return the comparator passed to this delete tracker
- getCellComparator() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.NewVersionBehaviorTracker
- getCellComparator() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanDeleteTracker
- getCellComparator() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
The comparator to be used with the region
- getCellComparator(byte[]) - Static method in class org.apache.hadoop.hbase.CellComparatorImpl
-
Utility method that makes a guess at comparator to use based off passed tableName.
- getCellComparator(TableName) - Static method in class org.apache.hadoop.hbase.CellComparatorImpl
-
Utility method that makes a guess at comparator to use based off passed tableName.
- getCellCount() - Method in class org.apache.hadoop.hbase.regionserver.MiniBatchOperationInProgress
- getCellKeyAsString(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Returns The Key portion of the passed
cell
as a String. - getCellKeyAsString(Cell, Function<Cell, String>) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Return the Key portion of the passed
cell
as a String. - getCellKeySerializedAsKeyValueKey(ExtendedCell) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
This method exists just to encapsulate how we serialize keys.
- getCells() - Method in class org.apache.hadoop.hbase.wal.WALEdit
- getCellScanner() - Method in interface org.apache.hadoop.hbase.ipc.RpcCall
-
Returns The CellScanner that can carry input and result payload.
- getCellScanner() - Method in class org.apache.hadoop.hbase.ipc.ServerCall
- getCellsCount() - Method in class org.apache.hadoop.hbase.regionserver.CompositeImmutableSegment
-
Returns number of cells in segment
- getCellsCount() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreSize
- getCellsCount() - Method in interface org.apache.hadoop.hbase.regionserver.MemStoreSizing
- getCellsCount() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreSnapshot
-
Returns Number of Cells in this snapshot.
- getCellsCount() - Method in class org.apache.hadoop.hbase.regionserver.Segment
- getCellsCountCompactedFromMob() - Method in class org.apache.hadoop.hbase.regionserver.HMobStore
- getCellsCountCompactedFromMob() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Gets the number of cells moved from mob during compaction.
- getCellsCountCompactedToMob() - Method in class org.apache.hadoop.hbase.regionserver.HMobStore
- getCellsCountCompactedToMob() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Gets the number of cells moved to mob during compaction.
- getCellSet() - Method in class org.apache.hadoop.hbase.regionserver.CompositeImmutableSegment
-
Returns a set of all cells in the segment
- getCellSet() - Method in class org.apache.hadoop.hbase.regionserver.Segment
-
Returns a set of all cells in the segment
- getCellsSizeCompactedFromMob() - Method in class org.apache.hadoop.hbase.regionserver.HMobStore
- getCellsSizeCompactedFromMob() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Gets the total amount of cells moved from mob during compaction, in bytes.
- getCellsSizeCompactedToMob() - Method in class org.apache.hadoop.hbase.regionserver.HMobStore
- getCellsSizeCompactedToMob() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Gets the total amount of cells moved to mob during compaction, in bytes.
- getCellTTLColumnIndex() - Method in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
- getCellValueFromProto(Q) - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
-
This method gets the PB message corresponding to the cell type
- getCellVisibility() - Method in class org.apache.hadoop.hbase.client.Mutation
-
Returns CellVisibility associated with cells in this Mutation.
- getCellVisibilityColumnIndex() - Method in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
- getChance() - Method in class org.apache.hadoop.hbase.filter.RandomRowFilter
-
Returns The chance that a row gets included.
- getChar() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.Cell
- getCharacter() - Method in class org.apache.hadoop.hbase.hbtop.terminal.KeyPress
- getCheckAndMutateChecksFailed() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
- getCheckAndMutateChecksFailed() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the number of CAS operations that failed.
- getCheckAndMutateChecksFailed() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Returns the number of failed checkAndMutate guards
- getCheckAndMutateChecksPassed() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
- getCheckAndMutateChecksPassed() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the number of CAS operations that passed.
- getCheckAndMutateChecksPassed() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Returns the number of checkAndMutate guards that passed
- getCheckAndMutateResult(ClientProtos.MutateResponse, CellScanner) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ResponseConverter
-
Create a CheckAndMutateResult object from a protocol buffer MutateResponse
- getChecksumFailures() - Method in interface org.apache.hadoop.hbase.io.MetricsIOWrapper
- getChecksumFailures() - Method in class org.apache.hadoop.hbase.io.MetricsIOWrapperImpl
- getChecksumFailuresCount() - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
-
Number of checksum verification failures.
- getChecksumType() - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
- getChecksumType(Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.StoreUtils
-
Returns the configured checksum algorithm.
- getChildDataAndWatchForNewChildren(ZKWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Deprecated.Unused
- getChildDataAndWatchForNewChildren(ZKWatcher, String, boolean) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Deprecated.Unused
- getChildren(String, boolean) - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
getChildren is an idempotent operation.
- getChildren(String, Watcher) - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
getChildren is an idempotent operation.
- getChoreService() - Method in class org.apache.hadoop.hbase.HBaseServerBase
- getChoreService() - Method in class org.apache.hadoop.hbase.MockRegionServerServices
- getChoreService() - Method in interface org.apache.hadoop.hbase.Server
-
Returns The
ChoreService
instance for this server - getChunkId() - Method in interface org.apache.hadoop.hbase.ExtendedCell
-
Extracts the id of the backing bytebuffer of this cell if it was obtained from fixed sized chunks as in case of MemstoreLAB
- getChunkId() - Method in class org.apache.hadoop.hbase.regionserver.ByteBufferChunkKeyValue
- getChunkId() - Method in class org.apache.hadoop.hbase.regionserver.NoTagByteBufferChunkKeyValue
- getCipher() - Method in class org.apache.hadoop.hbase.io.crypto.Context
- getCipher(String) - Method in interface org.apache.hadoop.hbase.io.crypto.CipherProvider
-
Get an Cipher
- getCipher(String) - Method in class org.apache.hadoop.hbase.io.crypto.CryptoCipherProvider
- getCipher(String) - Method in class org.apache.hadoop.hbase.io.crypto.DefaultCipherProvider
- getCipher(Configuration, String) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
-
Get an cipher given a name
- getCipherProvider(Configuration) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
- getClass(String, Class<?>) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
- getClass(String, Class<? extends U>, Class<U>) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
- getClassByName(String) - Method in class org.apache.hadoop.hbase.CompoundConfiguration
- getClassByName(String) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
- getClassByNameOrNull(String) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
- getClasses(String, Class<?>...) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
- getClassLoader() - Method in class org.apache.hadoop.hbase.coprocessor.BaseEnvironment
- getClassLoader() - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
- getClassLoader() - Method in interface org.apache.hadoop.hbase.CoprocessorEnvironment
-
Returns the classloader for the loaded coprocessor instance
- getClassLoader() - Static method in class org.apache.hadoop.hbase.util.ReflectionUtils
- getClassLoader(Path, ClassLoader, String, Configuration) - Static method in class org.apache.hadoop.hbase.util.CoprocessorClassLoader
-
Get a CoprocessorClassLoader for a coprocessor jar path from cache.
- getClassName() - Method in interface org.apache.hadoop.hbase.client.CoprocessorDescriptor
-
Returns the name of the class or interface represented by this object.
- getClassName() - Method in class org.apache.hadoop.hbase.namequeues.RpcLogDetails
- getClassName() - Method in class org.apache.hadoop.hbase.tool.coprocessor.CoprocessorViolation
- getClazz() - Method in enum class org.apache.hadoop.hbase.replication.ReplicationPeerStorageType
- getClientAddress() - Method in class org.apache.hadoop.hbase.client.LogQueryFilter
-
Deprecated.
- getClientAddress() - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord
- getClientAddress() - Method in class org.apache.hadoop.hbase.namequeues.RpcLogDetails
- getClientCertificateChain() - Method in interface org.apache.hadoop.hbase.ipc.RpcCallContext
-
Returns the TLS certificate(s) that the client presented to this HBase server when making its connection.
- getClientCertificateChain() - Method in class org.apache.hadoop.hbase.ipc.ServerCall
- getClientIdAuditPrefix() - Method in class org.apache.hadoop.hbase.master.HMaster
-
Returns Client info for use as prefix on an audit log string; who did an action
- getClientIdAuditPrefix() - Method in interface org.apache.hadoop.hbase.master.MasterServices
- getClientMetrics() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsUserSource
-
Metrics collected at client level for a user(needed for reporting through clusterStatus and hbtop currently)
- getClientMetrics() - Method in class org.apache.hadoop.hbase.regionserver.MetricsUserSourceImpl
- getClientMetrics() - Method in interface org.apache.hadoop.hbase.UserMetrics
-
Returns metrics per client(hostname)
- getClientPort() - Method in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
- getClientPort() - Method in class org.apache.hadoop.hbase.zookeeper.ZKConfig.ZKClusterKey
- getClientPortList() - Method in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
-
Get the list of client ports.
- getClientVersionInfo() - Method in interface org.apache.hadoop.hbase.ipc.RpcCallContext
-
Returns the client version info, or null if the information is not present
- getClientVersionInfo() - Method in class org.apache.hadoop.hbase.ipc.ServerCall
- getClientZKQuorumServersString(Configuration) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKConfig
-
Get the client ZK Quorum servers string
- getClosedRegions() - Method in class org.apache.hadoop.hbase.client.RegionStatesCount
- getCloseMetrics() - Method in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
-
Returns
OperationMetrics
containing common metrics for close region request - getCloseMetrics() - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManagerSourceImpl
- getCloseProcMetrics() - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManager
-
Returns Set of common metrics for CloseRegionProcedure
- getClosestRowBefore(Region, byte[], byte[]) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- getCluster() - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Returns the cluster definition
- getClusterId() - Method in class org.apache.hadoop.hbase.client.MasterRegistry
- getClusterId() - Method in interface org.apache.hadoop.hbase.client.Connection
-
Returns the cluster ID unique to this HBase cluster.
- getClusterId() - Method in interface org.apache.hadoop.hbase.client.ConnectionRegistry
-
Should only be called once.
- getClusterId() - Method in interface org.apache.hadoop.hbase.client.ConnectionRegistryEndpoint
-
Get cluster id.
- getClusterId() - Method in class org.apache.hadoop.hbase.client.SharedConnection
- getClusterId() - Method in interface org.apache.hadoop.hbase.ClusterMetrics
- getClusterId() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.Summary
- getClusterId() - Method in class org.apache.hadoop.hbase.master.HMaster
- getClusterId() - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
-
Returns The unique identifier generated for this cluster
- getClusterId() - Method in interface org.apache.hadoop.hbase.master.MetricsMasterWrapper
-
Get the Cluster ID
- getClusterId() - Method in class org.apache.hadoop.hbase.master.MetricsMasterWrapperImpl
- getClusterId() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
- getClusterId() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the Cluster ID
- getClusterId() - Method in class org.apache.hadoop.hbase.replication.ReplicationEndpoint.Context
- getClusterId() - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
- getClusterId() - Method in class org.apache.hadoop.hbase.util.ConnectionCache
-
Returns Cluster ID for the HBase cluster or null if there is an err making the connection.
- getClusterId(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Returns the value of the unique cluster ID stored for this HBase instance.
- getClusterId(RpcController, RegistryProtos.GetClusterIdRequest) - Method in class org.apache.hadoop.hbase.HBaseRpcServicesBase
- getClusterIds() - Method in class org.apache.hadoop.hbase.client.Mutation
-
Returns the set of clusterIds that have consumed the mutation
- getClusterIds() - Method in class org.apache.hadoop.hbase.wal.WALKeyImpl
-
Returns the set of cluster Ids that have consumed the change
- getClusterKey() - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.since 2.7.0, will be removed in 4.0.0. Now we use connection uri to specify the connection info of a cluster. Keep here only for compatibility.
- getClusterKey() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
- getClusterMetrics() - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get whole cluster metrics, containing status about:
- getClusterMetrics() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Returns cluster status wrapped by
CompletableFuture
- getClusterMetrics() - Method in class org.apache.hadoop.hbase.HBaseCluster
-
Deprecated.Returns a ClusterMetrics for this HBase cluster.
- getClusterMetrics() - Method in class org.apache.hadoop.hbase.master.HMaster
-
Returns cluster status
- getClusterMetrics() - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.
- getClusterMetrics(EnumSet<ClusterMetrics.Option>) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get cluster status with a set of
ClusterMetrics.Option
to get desired status. - getClusterMetrics(EnumSet<ClusterMetrics.Option>) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Returns cluster status wrapped by
CompletableFuture
- getClusterMetrics(EnumSet<ClusterMetrics.Option>) - Method in class org.apache.hadoop.hbase.master.HMaster
- getClusterMetricsWithoutCoprocessor() - Method in class org.apache.hadoop.hbase.master.HMaster
- getClusterMetricsWithoutCoprocessor(EnumSet<ClusterMetrics.Option>) - Method in class org.apache.hadoop.hbase.master.HMaster
- getClusterSchema() - Method in class org.apache.hadoop.hbase.master.HMaster
- getClusterSchema() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Returns Master's instance of
ClusterSchema
- getClusterStatus(RpcController, MasterProtos.GetClusterStatusRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- getClusterStatusResource() - Method in class org.apache.hadoop.hbase.rest.RootResource
- getClusterVersionResource() - Method in class org.apache.hadoop.hbase.rest.VersionResource
-
Dispatch to StorageClusterVersionResource
- getCode() - Method in enum class org.apache.hadoop.hbase.Cell.Type
- getCode() - Method in enum class org.apache.hadoop.hbase.KeyValue.Type
- getCode() - Method in class org.apache.hadoop.hbase.regionserver.RegionServerServices.RegionStateTransitionContext
- getCode() - Method in class org.apache.hadoop.hbase.rest.client.Response
-
Returns the HTTP response code
- getCode() - Method in enum class org.apache.hadoop.hbase.util.ChecksumType
- getCodec() - Method in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
-
Encapsulate the ugly casting and RuntimeException conversion in private method.
- getCodec(Configuration, Decryptor) - Static method in class org.apache.hadoop.hbase.regionserver.wal.SecureWALCellCodec
- getCodec(Configuration, Encryptor) - Static method in class org.apache.hadoop.hbase.regionserver.wal.SecureWALCellCodec
- getCodecClsName() - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractProtobufWALReader
-
Returns the cell codec classname
- getColumn() - Method in class org.apache.hadoop.hbase.hbtop.terminal.CursorPosition
- getColumnCells(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Result
-
Return the Cells for the specific column.
- getColumnDescriptors(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
- getColumnFamilies() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
Returns an unmodifiable collection of all the
ColumnFamilyDescriptor
of all the column families of the table. - getColumnFamilies() - Method in class org.apache.hadoop.hbase.util.LoadTestTool
- getColumnFamilies() - Method in class org.apache.hadoop.hbase.util.MultiThreadedAction.DefaultDataGenerator
- getColumnFamily() - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
- getColumnFamily(byte[]) - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
Returns the ColumnDescriptor for a specific column family with name as specified by the parameter column.
- getColumnFamilyCount() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
Returns the count of the column families of the table.
- getColumnFamilyDescriptor() - Method in class org.apache.hadoop.hbase.regionserver.HStore
- getColumnFamilyDescriptor() - Method in interface org.apache.hadoop.hbase.regionserver.Store
- getColumnFamilyMap() - Method in class org.apache.hadoop.hbase.client.replication.TableCFs
- getColumnFamilyName() - Method in class org.apache.hadoop.hbase.regionserver.HStore
- getColumnFamilyName() - Method in interface org.apache.hadoop.hbase.regionserver.Store
- getColumnFamilyName() - Method in interface org.apache.hadoop.hbase.regionserver.StoreConfigInformation
- getColumnFamilyNames() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
Returns all the column family names of the current table.
- getColumnFamilyTimeRange() - Method in class org.apache.hadoop.hbase.client.ImmutableScan
- getColumnFamilyTimeRange() - Method in class org.apache.hadoop.hbase.client.Query
-
Returns A map of column families to time ranges
- getColumnHint() - Method in interface org.apache.hadoop.hbase.regionserver.querymatcher.ColumnTracker
-
Used by matcher and scan/get to get a hint of the next column to seek to after checkColumn() returns SKIP.
- getColumnHint() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ExplicitColumnTracker
- getColumnHint() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.NewVersionBehaviorTracker
- getColumnHint() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanWildcardColumnTracker
-
Used by matcher and scan/get to get a hint of the next column to seek to after checkColumn() returns SKIP.
- getColumnLatestCell(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Result
-
The Cell for the most recent timestamp for a given column.
- getColumnLatestCell(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.client.Result
-
The Cell for the most recent timestamp for a given column.
- getColumnOffset() - Method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
- getColumns() - Method in class org.apache.hadoop.hbase.hbtop.terminal.TerminalSize
- getColumns() - Method in class org.apache.hadoop.hbase.rest.RowSpec
- getColumnsAdded() - Method in class org.apache.hadoop.hbase.client.TableDescriptorUtils.TableDescriptorDelta
- getColumnsDeleted() - Method in class org.apache.hadoop.hbase.client.TableDescriptorUtils.TableDescriptorDelta
- getColumnsModified() - Method in class org.apache.hadoop.hbase.client.TableDescriptorUtils.TableDescriptorDelta
- getCommmand() - Static method in class org.apache.hadoop.hbase.util.JSONMetricUtil
- getCommonOptions() - Method in class org.apache.hadoop.hbase.util.compaction.MajorCompactor
- getCompactedCellCount() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
Returns the number of already compacted kvs in current compaction
- getCompactedCellsCount() - Method in class org.apache.hadoop.hbase.regionserver.HStore
- getCompactedCellsCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the number of cells processed during minor compactions.
- getCompactedCellsCount() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Returns The number of cells processed during minor compactions
- getCompactedCellsSize() - Method in class org.apache.hadoop.hbase.regionserver.HStore
- getCompactedCellsSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the total amount of data processed during minor compactions, in bytes.
- getCompactedCellsSize() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Returns The total amount of data processed during minor compactions, in bytes
- getCompactedfiles() - Method in interface org.apache.hadoop.hbase.regionserver.StoreFileManager
-
List of compacted files inside this store that needs to be excluded in reads because further new reads will be using only the newly created files out of compaction.
- getCompactedfiles() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
- getCompactedFiles() - Method in class org.apache.hadoop.hbase.regionserver.HStore
- getCompactedFiles() - Method in interface org.apache.hadoop.hbase.regionserver.Store
- getCompactedFilesCount() - Method in class org.apache.hadoop.hbase.regionserver.HStore
- getCompactedFilesCount() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Returns Count of compacted store files
- getCompactedFilesCount() - Method in interface org.apache.hadoop.hbase.regionserver.StoreFileManager
-
Returns the number of compacted files.
- getCompactedFilesCount() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
- getCompactedFilesSupplier() - Method in class org.apache.hadoop.hbase.regionserver.StoreContext
- getCompactedHFilesDischarger() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
- getCompactingCellCount() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
Returns the total number of cells in current compaction
- getCompaction(Cell) - Static method in class org.apache.hadoop.hbase.wal.WALEdit
-
Deserialized and returns a CompactionDescriptor is the KeyValue contains one.
- getCompactionCheckMultiplier() - Method in class org.apache.hadoop.hbase.regionserver.HStore
- getCompactionCheckMultiplier() - Method in interface org.apache.hadoop.hbase.regionserver.StoreConfigInformation
- getCompactionCompressionType() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Returns Compression type setting.
- getCompactionPolicy() - Method in class org.apache.hadoop.hbase.regionserver.StoreEngine
-
Returns Compaction policy to use.
- getCompactionPressure() - Method in class org.apache.hadoop.hbase.client.backoff.ServerStatistics.RegionStatistics
- getCompactionPressure() - Method in class org.apache.hadoop.hbase.client.RegionLoadStats
- getCompactionPressure() - Method in class org.apache.hadoop.hbase.MockRegionServerServices
- getCompactionPressure() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
- getCompactionPressure() - Method in class org.apache.hadoop.hbase.regionserver.HStore
- getCompactionPressure() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
- getCompactionPressure() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
This value can represent the degree of emergency of compaction for this store.
- getCompactionPressure() - Method in interface org.apache.hadoop.hbase.regionserver.StoreFileManager
- getCompactionPressure() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
- getCompactionProgress() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
getter for CompactionProgress object
- getCompactionQueueSize() - Method in class org.apache.hadoop.hbase.regionserver.CompactSplit
-
Returns the current size of the queue containing regions that are processed.
- getCompactionQueueSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the size of the compaction queue
- getCompactionRequestor() - Method in class org.apache.hadoop.hbase.MockRegionServerServices
- getCompactionRequestor() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
- getCompactionRequestor() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
- getCompactionState() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
Returns the compaction state of this region
- getCompactionState() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
- getCompactionState() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Returns if a given region is in compaction now.
- getCompactionState(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get the current compaction state of a table.
- getCompactionState(TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Get the current compaction state of a table.
- getCompactionState(TableName) - Method in class org.apache.hadoop.hbase.master.HMaster
-
Get the compaction state of the table
- getCompactionState(TableName, CompactType) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get the current compaction state of a table.
- getCompactionState(TableName, CompactType) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Get the current compaction state of a table.
- getCompactionStateForRegion(byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get the current compaction state of region.
- getCompactionStateForRegion(byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Get the current compaction state of region.
- getCompactionThroughputController() - Method in class org.apache.hadoop.hbase.regionserver.CompactSplit
- getCompactor() - Method in class org.apache.hadoop.hbase.regionserver.StoreEngine
-
Returns Compactor to use.
- getCompactPriority() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Returns The priority that this region should have in the compaction queue
- getCompactPriority() - Method in class org.apache.hadoop.hbase.regionserver.HStore
- getCompactPriority() - Method in interface org.apache.hadoop.hbase.regionserver.Store
- getCompactSplitThread() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Returns the underlying
CompactSplit
for the servers - getComparator() - Method in class org.apache.hadoop.hbase.filter.ColumnValueFilter
-
Returns the comparator
- getComparator() - Method in class org.apache.hadoop.hbase.filter.CompareFilter
-
Returns the comparator
- getComparator() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
Returns the comparator
- getComparator() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
- getComparator() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
-
Returns comparator
- getComparator() - Method in class org.apache.hadoop.hbase.regionserver.AbstractMemStore
- getComparator() - Method in class org.apache.hadoop.hbase.regionserver.HStore
- getComparator() - Method in class org.apache.hadoop.hbase.regionserver.HStoreFile
- getComparator() - Method in class org.apache.hadoop.hbase.regionserver.KeyValueHeap.KVScannerComparator
- getComparator() - Method in class org.apache.hadoop.hbase.regionserver.ScanInfo
- getComparator() - Method in class org.apache.hadoop.hbase.regionserver.Segment
-
Returns the Cell comparator used by this segment
- getComparator() - Method in interface org.apache.hadoop.hbase.regionserver.Store
- getComparator() - Method in class org.apache.hadoop.hbase.regionserver.StoreContext
- getComparator() - Method in interface org.apache.hadoop.hbase.regionserver.StoreFile
-
Get the comparator for comparing two cells.
- getComparator() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileReader
- getComparator(Comparator<ColumnFamilyDescriptor>) - Static method in interface org.apache.hadoop.hbase.client.TableDescriptor
- getComparatorClassName() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
- getCompareOp() - Method in class org.apache.hadoop.hbase.client.CheckAndMutate
-
Returns the comparison operator
- getCompareOperator() - Method in class org.apache.hadoop.hbase.filter.ColumnValueFilter
-
Returns operator
- getCompareOperator() - Method in class org.apache.hadoop.hbase.filter.CompareFilter
- getCompareOperator() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
- getComparisonData() - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.RowRange
- getCompletedSequenceId() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
This does not really belong inside RegionLoad but its being done in the name of expediency.
- getCompletedSnapshotDir(String, Path) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
Get the directory for a completed snapshot.
- getCompletedSnapshotDir(SnapshotProtos.SnapshotDescription, Path) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
Get the directory for a specified snapshot.
- getCompletedSnapshots(RpcController, MasterProtos.GetCompletedSnapshotsRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
List the currently available/stored snapshots.
- getCompleteTs() - Method in class org.apache.hadoop.hbase.backup.BackupInfo
- getCompletionAction() - Method in class org.apache.hadoop.hbase.regionserver.MultiVersionConcurrencyControl.WriteEntry
- getCompletionTime() - Method in interface org.apache.hadoop.hbase.ServerTask
-
Get the task completion time.
- getCompletionTimestamp() - Method in interface org.apache.hadoop.hbase.master.SnapshotSentinel
-
Returns -1 if the snapshot is in progress, otherwise the completion timestamp.
- getCompressedSize(Compression.Algorithm, Compressor, byte[], int, int) - Static method in class org.apache.hadoop.hbase.io.encoding.EncodedDataBlock
-
Find the size of compressed data assuming that buffer will be compressed using given algorithm.
- getCompression() - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
- getCompressionAlgorithm() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
- getCompressionAlgorithmByName(String) - Static method in class org.apache.hadoop.hbase.io.compress.Compression
- getCompressionCodec() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
- getCompressionType() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Returns Compression type setting.
- getCompressionType() - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
- getCompressor() - Method in enum class org.apache.hadoop.hbase.io.compress.Compression.Algorithm
- getComputedSteps() - Method in class org.apache.hadoop.hbase.client.BalancerDecision
- getComputedTotalCost() - Method in class org.apache.hadoop.hbase.client.BalancerDecision
- getConcurrentCallsPerServer() - Method in class org.apache.hadoop.hbase.client.MetricsConnection.CallStats
- getConf() - Method in class org.apache.hadoop.hbase.BaseConfigurable
- getConf() - Method in class org.apache.hadoop.hbase.HBaseCluster
-
Deprecated.
- getConf() - Method in class org.apache.hadoop.hbase.io.crypto.Context
- getConf() - Method in class org.apache.hadoop.hbase.io.crypto.CryptoCipherProvider
- getConf() - Method in class org.apache.hadoop.hbase.io.crypto.DefaultCipherProvider
- getConf() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
- getConf() - Method in class org.apache.hadoop.hbase.mapreduce.DefaultVisibilityExpressionResolver
- getConf() - Method in class org.apache.hadoop.hbase.mapreduce.GroupingTableMapper
-
Returns the current configuration.
- getConf() - Method in class org.apache.hadoop.hbase.mapreduce.HRegionPartitioner
-
Returns the current configuration.
- getConf() - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableInputFormat
-
Returns the current configuration.
- getConf() - Method in class org.apache.hadoop.hbase.mapreduce.SimpleTotalOrderPartitioner
- getConf() - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
Returns the current configuration.
- getConf() - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputFormat
- getConf() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
- getConf() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeers
- getConf() - Method in class org.apache.hadoop.hbase.rest.RESTServer
- getConf() - Method in interface org.apache.hadoop.hbase.testing.TestingHBaseCluster
-
Get configuration of this cluster.
- getConf() - Method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
- getConf() - Method in class org.apache.hadoop.hbase.util.MapreduceDependencyClasspathTool
- getConf() - Method in class org.apache.hadoop.hbase.wal.WALFactory
- getConfiguration() - Method in interface org.apache.hadoop.hbase.client.Admin
-
Returns Configuration used by the instance.
- getConfiguration() - Method in interface org.apache.hadoop.hbase.client.AsyncBufferedMutator
-
Returns the
Configuration
object used by this instance. - getConfiguration() - Method in interface org.apache.hadoop.hbase.client.AsyncConnection
-
Returns the
Configuration
object used by this instance. - getConfiguration() - Method in class org.apache.hadoop.hbase.client.AsyncConnectionImpl
- getConfiguration() - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
Returns the
Configuration
object used by this instance. - getConfiguration() - Method in interface org.apache.hadoop.hbase.client.BufferedMutator
-
Returns the
Configuration
object used by this instance. - getConfiguration() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Returns an unmodifiable map.
- getConfiguration() - Method in interface org.apache.hadoop.hbase.client.Connection
-
Returns Configuration instance being used by this Connection instance.
- getConfiguration() - Method in class org.apache.hadoop.hbase.client.SharedAsyncConnection
- getConfiguration() - Method in class org.apache.hadoop.hbase.client.SharedConnection
- getConfiguration() - Method in interface org.apache.hadoop.hbase.client.Table
-
Returns the
Configuration
object used by this instance. - getConfiguration() - Method in class org.apache.hadoop.hbase.coprocessor.BaseEnvironment
- getConfiguration() - Method in interface org.apache.hadoop.hbase.CoprocessorEnvironment
-
Returns a Read-only Configuration; throws
UnsupportedOperationException
if you try to set a configuration. - getConfiguration() - Method in class org.apache.hadoop.hbase.HBaseCommonTestingUtility
-
Deprecated.Returns this classes's instance of
Configuration
. - getConfiguration() - Method in class org.apache.hadoop.hbase.HBaseRpcServicesBase
- getConfiguration() - Method in class org.apache.hadoop.hbase.HBaseServerBase
- getConfiguration() - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Returns this classes's instance of
Configuration
. - getConfiguration() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
Returns the Configuration used by this LocalHBaseCluster
- getConfiguration() - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
- getConfiguration() - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.
- getConfiguration() - Method in class org.apache.hadoop.hbase.MockRegionServerServices
- getConfiguration() - Method in class org.apache.hadoop.hbase.NamespaceDescriptor
-
Getter for fetching an unmodifiable
NamespaceDescriptor.configuration
map. - getConfiguration() - Method in class org.apache.hadoop.hbase.regionserver.AbstractMemStore
- getConfiguration() - Method in class org.apache.hadoop.hbase.regionserver.HMobStore
-
Gets current config.
- getConfiguration() - Method in class org.apache.hadoop.hbase.replication.ReplicationEndpoint.Context
- getConfiguration() - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeer
-
Get the configuration object required to communicate with this peer
- getConfiguration() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
- getConfiguration() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerImpl
- getConfiguration() - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
-
Getter for fetching an unmodifiable
RSGroupInfo.configuration
map. - getConfiguration() - Method in interface org.apache.hadoop.hbase.Server
-
Gets the configuration object for this server.
- getConfiguration() - Method in class org.apache.hadoop.hbase.zookeeper.ZKWatcher
- getConfigurationManager() - Method in class org.apache.hadoop.hbase.HBaseServerBase
- getConfigurationValue(String) - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Returns accessing the configuration value by key.
- getConfigurationValue(String) - Method in class org.apache.hadoop.hbase.NamespaceDescriptor
-
Getter for accessing the configuration value by key
- getConfiguredHashAlgorithm(Configuration) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
-
Returns the Hash Algorithm defined in the crypto configuration.
- getConfiguredNamespacesAndTablesInRSGroup(String) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get the namespaces and tables which have this RegionServer group in descriptor.
- getConfiguredNamespacesAndTablesInRSGroup(String) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Get the namespaces and tables which have this RegionServer group in descriptor.
- getConfiguredNamespacesAndTablesInRSGroup(RpcController, RSGroupAdminProtos.GetConfiguredNamespacesAndTablesInRSGroupRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- getConfResourceAsInputStream(String) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
- getConfResourceAsReader(String) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
- getConnectedZooKeeper(String, int) - Static method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperHelper
-
Get a ZooKeeper instance and wait until it connected before returning.
- getConnection() - Method in interface org.apache.hadoop.hbase.client.Admin
-
Returns Connection used by this object.
- getConnection() - Method in interface org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment
-
Returns the hosts' Connection to the Cluster.
- getConnection() - Method in interface org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment
-
Returns the hosts' Connection to the Cluster.
- getConnection() - Method in interface org.apache.hadoop.hbase.coprocessor.RegionServerCoprocessorEnvironment
-
Returns the hosts' Connection to the Cluster.
- getConnection() - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Get a shared Connection to the cluster.
- getConnection() - Method in class org.apache.hadoop.hbase.MockRegionServerServices
- getConnection() - Method in interface org.apache.hadoop.hbase.Server
-
Returns a reference to the servers' connection.
- getConnection(SocketChannel, long) - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcServer
-
Deprecated.Subclasses of HBaseServer can override this to provide their own Connection implementations.
- getConnection(User) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Get a assigned Connection to the cluster.
- getConnectionAttributes() - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord
- getConnectionAttributes() - Method in interface org.apache.hadoop.hbase.ipc.RpcCall
-
Returns the map of attributes specified when building the Connection.
- getConnectionAttributes() - Method in class org.apache.hadoop.hbase.ipc.ServerCall
- getConnectionAttributes() - Method in class org.apache.hadoop.hbase.namequeues.RpcLogDetails
- getConnectionCache() - Method in class org.apache.hadoop.hbase.rest.RESTServlet
-
Returns the ConnectionCache instance
- getConnectionCount() - Method in class org.apache.hadoop.hbase.client.MetricsConnection
-
Return the connection count of the metrics within a scope
- getConnectionExceptionTypes() - Static method in class org.apache.hadoop.hbase.exceptions.ClientExceptionsUtil
-
For test only.
- getConnectionRegistry() - Method in class org.apache.hadoop.hbase.client.AsyncConnectionImpl
- getConnectionString() - Method in interface org.apache.hadoop.hbase.client.ConnectionRegistry
-
Return the connection string associated with this registry instance.
- getConnectionString() - Method in class org.apache.hadoop.hbase.client.MasterRegistry
-
Deprecated.
- getConnectionString() - Method in class org.apache.hadoop.hbase.client.RpcConnectionRegistry
- getConnectorAddress(int) - Method in class org.apache.hadoop.hbase.http.HttpServer
-
Get the address that corresponds to a particular connector.
- getConnectString() - Method in class org.apache.hadoop.hbase.zookeeper.ReadOnlyZKClient
- getConsistency() - Method in class org.apache.hadoop.hbase.client.ImmutableScan
- getConsistency() - Method in class org.apache.hadoop.hbase.client.Query
-
Returns the consistency level for this operation
- getContext() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
- getContext() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
- getContext() - Method in class org.apache.hadoop.hbase.regionserver.HRegion.RowLockImpl
- getControllerException(RpcController) - Static method in class org.apache.hadoop.hbase.ipc.CoprocessorRpcUtils
-
Retreivies exception stored during RPC invocation.
- getControllerException(RpcController) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ResponseConverter
-
Retreivies exception stored during RPC invocation.
- getCoordinatedStateManager() - Method in class org.apache.hadoop.hbase.HBaseServerBase
- getCoordinatedStateManager() - Method in class org.apache.hadoop.hbase.MockRegionServerServices
- getCoordinatedStateManager() - Method in interface org.apache.hadoop.hbase.Server
-
Get CoordinatedStateManager instance for this server.
- getCoprocessorDescriptors() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
Return the list of attached co-processor represented
- getCoprocessorHost() - Method in class org.apache.hadoop.hbase.HBaseServerBase
- getCoprocessorHost() - Method in class org.apache.hadoop.hbase.master.HMaster
- getCoprocessorHost() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Returns the coprocessor host
- getCoprocessorHost() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
- getCoprocessorHost() - Method in class org.apache.hadoop.hbase.regionserver.HStore
- getCoprocessorHost() - Method in class org.apache.hadoop.hbase.regionserver.StoreContext
- getCoprocessorHost() - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
- getCoprocessorHost() - Method in interface org.apache.hadoop.hbase.wal.WAL
-
Returns Coprocessor host.
- getCoprocessorNames() - Method in interface org.apache.hadoop.hbase.ServerMetrics
-
Return the RegionServer-level and Region-level coprocessors
- getCoprocessors() - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
-
Used to create a parameter to the HServerLoad constructor so that HServerLoad can provide information about the coprocessors loaded by this regionserver.
- getCoprocessors() - Method in interface org.apache.hadoop.hbase.master.MetricsMasterWrapper
-
Get the co-processors
- getCoprocessors() - Method in class org.apache.hadoop.hbase.master.MetricsMasterWrapperImpl
- getCoprocessors() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the co-processors
- getCoprocessorServiceRequest(Descriptors.MethodDescriptor, Message) - Static method in class org.apache.hadoop.hbase.ipc.CoprocessorRpcUtils
- getCoprocessorServiceRequest(Descriptors.MethodDescriptor, Message, byte[], byte[]) - Static method in class org.apache.hadoop.hbase.ipc.CoprocessorRpcUtils
- getCorePoolSize() - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
- getCorePoolSize() - Method in interface org.apache.hadoop.hbase.thrift.IncrementCoalescerMBean
- getCorrupted() - Method in class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
-
Returns the set of corrupted file paths after checkTables is called.
- getCorruptedFlagFileForSnapshot(Path) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
Get the flag file path if the snapshot is corrupted
- getCorruptedMobFiles() - Method in class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
-
Returns the set of corrupted mob file paths after checkTables is called.
- getCorruptedStoreFilesCount() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
-
Returns the number of corrupted store files
- getCostFuncInfoList() - Method in class org.apache.hadoop.hbase.client.BalancerRejection
- getCount() - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil.CachedBlocksByFile
-
Returns count of blocks in the cache
- getCount() - Method in interface org.apache.hadoop.hbase.metrics.Counter
-
Returns the current value.
- getCount() - Method in interface org.apache.hadoop.hbase.metrics.Histogram
-
Return the total number of values added to the histogram.
- getCount() - Method in interface org.apache.hadoop.hbase.metrics.Meter
-
Returns the number of events.
- getCount() - Method in interface org.apache.hadoop.hbase.metrics.Snapshot
-
Returns the number of values in the snapshot.
- getCount() - Method in interface org.apache.hadoop.metrics2.MetricHistogram
-
Return the total number of values added to the histogram.
- getCountAtOrBelow(long) - Method in interface org.apache.hadoop.hbase.metrics.Snapshot
-
Returns the total count below the given value
- getCountersMapSize() - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
- getCountersMapSize() - Method in interface org.apache.hadoop.hbase.thrift.IncrementCoalescerMBean
- getCpRequestCount() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
Returns the number of coprocessor service requests made to region
- getCpRequestCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
-
Get the total number of CoprocessorService requests that have been issued against this region
- getCpRequestCount() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
- getCpRequestCount(String) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImpl
- getCpRequestsCount() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
- getCpRequestsCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the number of coprocessor requests to regions hosted on this region server.
- getCpRequestsCount() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Returns coprocessor requests count for this region
- getCpRequestsCount(String) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregate
-
Get the number of CoprocessorService requests that have been issued against this table
- getCpRequestsCount(String) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImpl
- getCreatedTimestamp() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
Returns timestamp when this file was created (as returned by filesystem)
- getCreationTime() - Method in class org.apache.hadoop.hbase.client.SnapshotDescription
- getCurBlock() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
- getCurBlockCacheSize() - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerContext
- getCurBlockCacheUsed() - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerContext
- getCurMemStoreSize() - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerContext
- getCurMemStoreUsed() - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerContext
- getCurrent() - Static method in class org.apache.hadoop.hbase.security.User
-
Returns the
User
instance within current execution context. - getCurrent() - Method in class org.apache.hadoop.hbase.security.UserProvider
-
Return the current user within the current execution context
- getCurrentBloomSize() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
- getCurrentCall() - Static method in class org.apache.hadoop.hbase.ipc.RpcServer
-
Needed for features such as delayed calls.
- getCurrentClientVersionInfo() - Static method in class org.apache.hadoop.hbase.client.VersionInfoUtil
-
Returns the versionInfo extracted from the current RpcCallContext
- getCurrentDataSize() - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCache
-
Returns the occupied size of data blocks, in bytes.
- getCurrentDataSize() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
- getCurrentDataSize() - Method in class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache
- getCurrentDataSize() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
- getCurrentDataSize() - Method in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
- getCurrentDataSize() - Method in class org.apache.hadoop.hbase.io.hfile.TinyLfuBlockCache
- getCurrentFileName() - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
This is a convenience method that computes a new filename with a given using the current WAL file-number
- getCurrentFileName(WAL) - Static method in class org.apache.hadoop.hbase.wal.AbstractFSWALProvider
-
return the current filename from the current wal.
- getCurrentFileSystem(Configuration) - Static method in class org.apache.hadoop.hbase.util.CommonFSUtils
-
Returns the filesystem of the hbase rootdir.
- getCurrentHash() - Method in class org.apache.hadoop.hbase.mapreduce.HashTable.TableHash.Reader
-
Get the current hash
- getCurrentIndexSize() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
- getCurrentKey() - Method in class org.apache.hadoop.hbase.mapreduce.HashTable.TableHash.Reader
-
Get the current key
- getCurrentKey() - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReader
-
Returns the current key.
- getCurrentKey() - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReaderImpl
-
Returns the current key.
- getCurrentKey() - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.RecordReader
- getCurrentMode() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenModel
- getCurrentParallelPutCount() - Method in class org.apache.hadoop.hbase.regionserver.HStore
- getCurrentParallelPutCount() - Method in interface org.apache.hadoop.hbase.regionserver.Store
- getCurrentPath() - Method in class org.apache.hadoop.hbase.io.FileLink.FileLinkInputStream
- getCurrentPosition() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.Paging
- getCurrentRegionCachedRatio() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
Returns current prefetch ratio of this region on this server
- getCurrentRegionCacheRatio() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
-
Gets the current cache % ratio for this region.
- getCurrentRegionCacheRatio() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
- getCurrentServerCallWithCellScanner() - Static method in class org.apache.hadoop.hbase.ipc.RpcServer
-
Just return the current rpc call if it is a
ServerCall
and also hasCellScanner
attached. - getCurrentSize() - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCache
-
Returns the occupied size of the block cache, in bytes.
- getCurrentSize() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
- getCurrentSize() - Method in class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache
- getCurrentSize() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
- getCurrentSize() - Method in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
- getCurrentSize() - Method in class org.apache.hadoop.hbase.io.hfile.TinyLfuBlockCache
- getCurrentSnapshotFromQuotaTable(Connection, TableName) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
Returns the current space quota snapshot of the given
tableName
fromQuotaTableUtil.QUOTA_TABLE_NAME
or null if the no quota information is available for that tableName. - getCurrentSortField() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenModel
- getCurrentSpaceQuotaSnapshot(String) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Returns the Master's view of a quota on the given
namespace
or null if the Master has no quota information on that namespace. - getCurrentSpaceQuotaSnapshot(String) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Returns the Master's view of a quota on the given
namespace
or null if the Master has no quota information on that namespace. - getCurrentSpaceQuotaSnapshot(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Returns the Master's view of a quota on the given
tableName
or null if the Master has no quota information on that table. - getCurrentSpaceQuotaSnapshot(TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Returns the Master's view of a quota on the given
tableName
or null if the Master has no quota information on that table. - getCurrentState(String) - Method in class org.apache.hadoop.hbase.quotas.NamespaceQuotaSnapshotStore
- getCurrentState(TableName) - Method in class org.apache.hadoop.hbase.quotas.TableQuotaSnapshotStore
- getCurrentState(T) - Method in interface org.apache.hadoop.hbase.quotas.QuotaSnapshotStore
-
Returns the current
SpaceQuotaSnapshot
for the givensubject
. - getCurrentTerm() - Method in class org.apache.hadoop.hbase.util.LossyCounting
- getCurrentTime() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.Summary
- getCurrentUserName() - Method in class org.apache.hadoop.hbase.security.UserProvider
-
Returns the userName for the current logged-in user.
- getCurrentValue() - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReader
-
Returns the current value.
- getCurrentValue() - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReaderImpl
-
Returns the current value.
- getCurrentValue() - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.RecordReader
- getCursor() - Method in class org.apache.hadoop.hbase.client.Result
-
Return the cursor if this Result is a cursor result.
- getCursorPosition() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.batch.BatchTerminal
- getCursorPosition() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.ScreenBuffer
- getCursorPosition() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.TerminalImpl
- getCursorPosition() - Method in interface org.apache.hadoop.hbase.hbtop.terminal.Terminal
- getCurTaskZKVersion() - Method in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination.ZkSplitTaskDetails
- getCurTotalNonRootEntrySize() - Method in interface org.apache.hadoop.hbase.io.hfile.BlockIndexChunk
- getData() - Method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.NodeAndData
-
Deprecated.
- getData() - Method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp.CreateAndFailSilent
- getData() - Method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp.SetData
- getData(boolean) - Method in class org.apache.hadoop.hbase.zookeeper.ZKNodeTracker
-
Gets the data of the node.
- getData(String, boolean, Stat) - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
getData is an idempotent operation.
- getData(String, Watcher, Stat) - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
getData is an idempotent operation.
- getData(ZKWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Get znode data.
- getDataAndWatch(ZKWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Get the data at the specified znode and set a watch.
- getDataAndWatch(ZKWatcher, String, boolean) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Get the data at the specified znode and set a watch.
- getDataAndWatch(ZKWatcher, String, Stat) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Get the data at the specified znode and set a watch.
- GetDataAsyncCallback() - Constructor for class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination.GetDataAsyncCallback
- getDataBlockCount() - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCache
-
Returns the number of data blocks currently cached in the block cache.
- getDataBlockCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
- getDataBlockCount() - Method in class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache
- getDataBlockCount() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
- getDataBlockCount() - Method in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
- getDataBlockCount() - Method in class org.apache.hadoop.hbase.io.hfile.TinyLfuBlockCache
- getDataBlockEncoder() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
Returns the data block encoder
- getDataBlockEncoderById(short) - Static method in enum class org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
-
Find and create data block encoder for given id;
- getDataBlockEncoding() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Returns the data block encoding algorithm used in block cache and optionally on disk
- getDataBlockEncoding() - Method in class org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultEncodingContext
- getDataBlockEncoding() - Method in interface org.apache.hadoop.hbase.io.encoding.HFileBlockEncodingContext
-
Returns the
DataBlockEncoding
encoding used - getDataBlockEncoding() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
- getDataBlockEncoding() - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
- getDataBlockEncoding() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoder
-
Returns the data block encoding
- getDataBlockEncoding() - Method in class org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoderImpl
- getDataBlockEncoding() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
- getDataBlockEncoding() - Method in class org.apache.hadoop.hbase.io.hfile.NoOpDataBlockEncoder
- getDataBlockIndexReader() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
- getDataBlockIndexReader() - Method in class org.apache.hadoop.hbase.io.hfile.HFileInfo
- getDataBlockIndexReader() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
- getDataChecksumType() - Method in enum class org.apache.hadoop.hbase.util.ChecksumType
-
Function to get corresponding
DataChecksum.Type
. - getDataCount() - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil.CachedBlocksByFile
- getDataHitCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
- getDataHitCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
- getDataHitCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
- getDataIndexCount() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
- getDataInMemoryWithoutWAL() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
- getDataInMemoryWithoutWAL() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Ammount of data in the memstore but not in the WAL because mutations explicitly had their WAL turned off.
- getDataInMemoryWithoutWAL() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Returns the size of data processed bypassing the WAL, in bytes
- getDataLocality() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
Returns the data locality of region in the regionserver.
- getDataLocalityForSsd() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
Different from dataLocality,this metric's numerator only include the data stored on ssd
- getDataMissCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
- getDataMissCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
- getDataMissCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
- getDataNodeHosts() - Method in class org.apache.hadoop.hbase.StartMiniClusterOption
-
Deprecated.
- getDataNodeHosts() - Method in class org.apache.hadoop.hbase.testing.TestingHBaseClusterOption
- getDataNodeInfo(Collection<DatanodeInfo>) - Static method in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputHelper
- getDataNodePort(Configuration) - Static method in class org.apache.hadoop.hbase.favored.FavoredNodeAssignmentHelper
- getDataNoWatch(ZKWatcher, String, Stat) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Get the data at the specified znode without setting a watch.
- getDataRootDir() - Method in class org.apache.hadoop.hbase.HBaseServerBase
-
Returns Return the rootDir.
- getDataSetWatchAsync() - Method in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination
- getDataSize() - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil.CachedBlocksByFile
-
Returns Size of data.
- getDataSize() - Method in class org.apache.hadoop.hbase.regionserver.CompositeImmutableSegment
-
Returns Sum of all cell sizes.
- getDataSize() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreSize
- getDataSize() - Method in interface org.apache.hadoop.hbase.regionserver.MemStoreSizing
- getDataSize() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreSnapshot
- getDataSize() - Method in class org.apache.hadoop.hbase.regionserver.Segment
- getDataSize() - Method in class org.apache.hadoop.hbase.util.LossyCounting
- getDataTestDir() - Method in class org.apache.hadoop.hbase.HBaseCommonTestingUtility
-
Deprecated.
- getDataTestDir(String) - Method in class org.apache.hadoop.hbase.HBaseCommonTestingUtility
-
Deprecated.
- getDataTestDirOnTestFS() - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Returns a Path in the test filesystem, obtained from
HBaseTestingUtility.getTestFileSystem()
to write temporary test data. - getDataTestDirOnTestFS(String) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Returns a Path in the test filesystem, obtained from
HBaseTestingUtility.getTestFileSystem()
to write temporary test data. - getDataTestDirOnTestFS(String) - Method in class org.apache.hadoop.hbase.util.WALPerformanceEvaluationUtil
-
Returns a Path in the test filesystem, obtained from
WALPerformanceEvaluationUtil.getTestFileSystem()
to write temporary test data. - getDataWriter() - Method in class org.apache.hadoop.hbase.io.hfile.CompoundBloomFilterWriter
- getDataWriter() - Method in interface org.apache.hadoop.hbase.util.BloomFilterWriter
-
Get a writable interface into bloom filter data (the actual Bloom bits).
- getDate() - Method in class org.apache.hadoop.hbase.mob.MobFileName
-
Gets the date string.
- getDate() - Static method in class org.apache.hadoop.hbase.util.VersionInfo
-
The date that hbase was compiled.
- getDateFromName(String) - Static method in class org.apache.hadoop.hbase.mob.MobFileName
-
get date from MobFileName.
- getDaughterRegions(Result) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Returns the daughter regions by reading the corresponding columns of the catalog table Result.
- getDeadline() - Method in interface org.apache.hadoop.hbase.ipc.RpcCall
-
Return the deadline of this call.
- getDeadline() - Method in class org.apache.hadoop.hbase.ipc.ServerCall
- getDeadline(RPCProtos.RequestHeader, Message) - Method in class org.apache.hadoop.hbase.HBaseRpcServicesBase
- getDeadline(RPCProtos.RequestHeader, Message) - Method in interface org.apache.hadoop.hbase.ipc.PriorityFunction
-
Returns the deadline of the specified request.
- getDeadline(RPCProtos.RequestHeader, Message) - Method in class org.apache.hadoop.hbase.master.MasterAnnotationReadingPriorityFunction
- getDeadRegionServers() - Method in interface org.apache.hadoop.hbase.master.MetricsMasterWrapper
-
Get the dead region servers
- getDeadRegionServers() - Method in class org.apache.hadoop.hbase.master.MetricsMasterWrapperImpl
- getDeadRegionServers() - Method in class org.apache.hadoop.hbase.replication.ReplicationQueueInfo
- getDeadServerNames() - Method in interface org.apache.hadoop.hbase.ClusterMetrics
-
Returns the names of region servers on the dead list
- getDeadServers() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.Summary
- getDeadServers() - Method in class org.apache.hadoop.hbase.master.ServerManager
- getDeadServers(long) - Method in class org.apache.hadoop.hbase.master.ClusterStatusPublisher
-
Get the servers which died since a given timestamp.
- getDecoder(InputStream) - Method in class org.apache.hadoop.hbase.codec.CellCodec
- getDecoder(InputStream) - Method in class org.apache.hadoop.hbase.codec.CellCodecWithTags
- getDecoder(InputStream) - Method in interface org.apache.hadoop.hbase.codec.Codec
- getDecoder(InputStream) - Method in class org.apache.hadoop.hbase.codec.KeyValueCodec
-
Implementation depends on
InputStream.available()
- getDecoder(InputStream) - Method in class org.apache.hadoop.hbase.codec.KeyValueCodecWithTags
-
Implementation depends on
InputStream.available()
- getDecoder(InputStream) - Method in class org.apache.hadoop.hbase.codec.MessageCodec
- getDecoder(InputStream) - Method in class org.apache.hadoop.hbase.regionserver.wal.SecureWALCellCodec
- getDecoder(InputStream) - Method in class org.apache.hadoop.hbase.regionserver.wal.WALCellCodec
- getDecoder(ByteBuff) - Method in class org.apache.hadoop.hbase.codec.CellCodec
- getDecoder(ByteBuff) - Method in class org.apache.hadoop.hbase.codec.CellCodecWithTags
- getDecoder(ByteBuff) - Method in interface org.apache.hadoop.hbase.codec.Codec
- getDecoder(ByteBuff) - Method in class org.apache.hadoop.hbase.codec.KeyValueCodec
- getDecoder(ByteBuff) - Method in class org.apache.hadoop.hbase.codec.KeyValueCodecWithTags
- getDecoder(ByteBuff) - Method in class org.apache.hadoop.hbase.codec.MessageCodec
- getDecoder(ByteBuff) - Method in class org.apache.hadoop.hbase.regionserver.wal.WALCellCodec
- getDecommissionedServerNames() - Method in interface org.apache.hadoop.hbase.ClusterMetrics
-
Returns the names of region servers on the decommissioned list
- getDecompressor() - Method in enum class org.apache.hadoop.hbase.io.compress.Compression.Algorithm
- getDecryptor() - Method in class org.apache.hadoop.hbase.io.crypto.aes.AES
- getDecryptor() - Method in class org.apache.hadoop.hbase.io.crypto.aes.CommonsCryptoAES
- getDecryptor() - Method in class org.apache.hadoop.hbase.io.crypto.Cipher
-
Return a decryptor for decrypting data.
- getDeepCopy() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.NewVersionBehaviorTracker.DeleteVersionsNode
- getDefaultBlockSize(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.CommonFSUtils
-
Return the number of bytes that large input files should be optimally be split into to minimize i/o time.
- getDefaultBufferSize(FileSystem) - Static method in class org.apache.hadoop.hbase.util.CommonFSUtils
-
Returns the default buffer size to use during writes.
- getDefaultChecksumType() - Static method in enum class org.apache.hadoop.hbase.util.ChecksumType
- getDefaultCodec(Configuration) - Static method in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
- getDefaultFileExtension() - Method in enum class org.apache.hadoop.hbase.io.crypto.tls.KeyStoreFileType
-
The file extension that is associated with this file type.
- getDefaultHost(String, String) - Static method in class org.apache.hadoop.hbase.util.DNS
-
Wrapper around DNS.getDefaultHost(String, String), calling DNS.getDefaultHost(String, String, boolean) when available.
- getDefaultLength() - Method in class org.apache.hadoop.hbase.hbtop.field.FieldInfo
- getDefaultParameters(Configuration) - Static method in class org.apache.hadoop.hbase.http.ClickjackingPreventionFilter
- getDefaultParameters(Configuration, boolean) - Static method in class org.apache.hadoop.hbase.http.SecurityHeadersFilter
- getDefaultPort() - Method in class org.apache.hadoop.hbase.HBaseRpcServicesBase
- getDefaultPort() - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- getDefaultPort() - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
- getDefaultRegionLocation() - Method in class org.apache.hadoop.hbase.RegionLocations
- getDefaultReplication(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.CommonFSUtils
- getDefaultRootDirPath() - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Same as {
HBaseTestingUtility.getDefaultRootDirPath(boolean create)
except thatcreate
flag is false. - getDefaultRootDirPath(boolean) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Returns the path to the default root dir the minicluster uses.
- getDefaultSortField() - Method in class org.apache.hadoop.hbase.hbtop.mode.ClientModeStrategy
- getDefaultSortField() - Method in enum class org.apache.hadoop.hbase.hbtop.mode.Mode
- getDefaultSortField() - Method in class org.apache.hadoop.hbase.hbtop.mode.NamespaceModeStrategy
- getDefaultSortField() - Method in class org.apache.hadoop.hbase.hbtop.mode.RegionModeStrategy
- getDefaultSortField() - Method in class org.apache.hadoop.hbase.hbtop.mode.RegionServerModeStrategy
- getDefaultSortField() - Method in class org.apache.hadoop.hbase.hbtop.mode.TableModeStrategy
- getDefaultSortField() - Method in class org.apache.hadoop.hbase.hbtop.mode.UserModeStrategy
- getDefaultValues() - Static method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
- getDelay(TimeUnit) - Method in class org.apache.hadoop.hbase.JitterScheduledThreadPoolExecutorImpl.JitteredRunnableScheduledFuture
- getDelegate() - Method in class org.apache.hadoop.hbase.io.DelegatingInputStream
- getDelegate() - Static method in class org.apache.hadoop.hbase.util.EnvironmentEdgeManager
-
Retrieves the singleton instance of the
EnvironmentEdge
that is being managed. - getDeletableFiles(Iterable<FileStatus>) - Method in class org.apache.hadoop.hbase.backup.BackupHFileCleaner
- getDeleteBloomFilterMetadata() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
-
Retrieves delete family Bloom filter metadata as appropriate for each
HFile
version. - getDeleteBloomFilterMetadata() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
- getDeleteFamilyBloomHitCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
- getDeleteFamilyBloomHitCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
- getDeleteFamilyBloomHitCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
- getDeleteFamilyBloomMissCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
- getDeleteFamilyBloomMissCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
- getDeleteFamilyBloomMissCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
- getDeleteFamilyCnt() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileReader
- getDeleteTracker() - Method in class org.apache.hadoop.hbase.client.MetricsConnection
-
deleteTracker metric
- getDelimiter(byte[], int, int, int) - Static method in class org.apache.hadoop.hbase.KeyValue
-
Find index of passed delimiter walking from start of buffer forwards.
- getDelimiterInReverse(byte[], int, int, int) - Static method in class org.apache.hadoop.hbase.KeyValue
-
Find index of passed delimiter walking from end of buffer backwards.
- getDeployedOn() - Method in class org.apache.hadoop.hbase.util.HbckRegionInfo
- getDesc(List<Throwable>, List<? extends Row>, List<String>) - Static method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
- getDesc(Map<String, Integer>) - Static method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
- getDescription() - Method in enum class org.apache.hadoop.hbase.hbtop.field.Field
- getDescription() - Method in enum class org.apache.hadoop.hbase.hbtop.mode.Mode
- getDescription() - Method in class org.apache.hadoop.hbase.hbtop.screen.help.CommandDescription
- getDescription() - Method in interface org.apache.hadoop.hbase.ServerTask
-
Get the task's description.
- getDescription() - Method in enum class org.apache.hadoop.hbase.thrift.ImplType
- getDescriptiveNameFromRegionStateForDisplay(RegionState, Configuration) - Static method in class org.apache.hadoop.hbase.client.RegionInfoDisplay
-
Get the descriptive name as
RegionState
does it but with hidden startkey optionally - getDescriptor() - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
Gets the
TableDescriptor
for this table. - getDescriptor() - Method in interface org.apache.hadoop.hbase.client.Table
-
Gets the
table descriptor
for this table. - getDescriptor(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get a table descriptor.
- getDescriptor(TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Method for getting the tableDescriptor
- getDeserializer() - Method in interface org.apache.hadoop.hbase.io.hfile.Cacheable
-
Returns CacheableDeserializer instance which reconstructs original object from ByteBuffer.
- getDeserializer() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
- getDeserializer(int) - Static method in class org.apache.hadoop.hbase.io.hfile.CacheableDeserializerIdManager
-
Get the cacheable deserializer registered at the given identifier Id.
- getDeserializer(Class<Cell>) - Method in class org.apache.hadoop.hbase.mapreduce.CellSerialization
- getDeserializer(Class<Mutation>) - Method in class org.apache.hadoop.hbase.mapreduce.MutationSerialization
- getDeserializer(Class<Result>) - Method in class org.apache.hadoop.hbase.mapreduce.ResultSerialization
- getDeserializer(Class<ExtendedCell>) - Method in class org.apache.hadoop.hbase.mapreduce.ExtendedCellSerialization
- getDeserializerIdentifier() - Method in interface org.apache.hadoop.hbase.io.hfile.CacheableDeserializer
-
Get the identifier of this deserializer.
- getDeserializerIdentifier() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock.BlockDeserializer
- getDestination() - Method in class org.apache.hadoop.hbase.master.RegionPlan
-
Get the destination server for the plan for this region.
- getDetails() - Method in interface org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination
-
Deprecated.Returns the configuration that was provided previously
- getDetails() - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
- getDeterministicRandomSeed(Collection<HStoreFile>) - Static method in class org.apache.hadoop.hbase.regionserver.StoreUtils
-
Creates a deterministic hash code for store file collection.
- getDeterministicUniqueKey(long) - Method in class org.apache.hadoop.hbase.util.MultiThreadedAction.DefaultDataGenerator
- getDeviation() - Method in class org.apache.hadoop.hbase.util.RollingStatCalculator
-
Returns deviation of the data values that are in the current list of data values
- getDFSCluster() - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- getDFSHedgedReadMetrics(Configuration) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Returns The DFSClient DFSHedgedReadMetrics instance or null if can't be found or not on hdfs.
- getDFSReplication() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Returns replication factor set for this CF
- getDictionary(Enum) - Method in class org.apache.hadoop.hbase.regionserver.wal.CompressionContext
- getDictionary(Configuration, String) - Static method in class org.apache.hadoop.hbase.io.compress.DictionaryCache
-
Load a dictionary or return a previously cached load.
- getDifferentUser(Configuration, String) - Static method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.This method clones the passed
c
configuration setting a new user into the clone. - getDirectMemorySize() - Static method in class org.apache.hadoop.hbase.util.DirectMemoryUtils
-
Returns the direct memory limit of the current progress
- getDirectMemoryUsage() - Static method in class org.apache.hadoop.hbase.util.DirectMemoryUtils
-
Returns the current amount of direct memory used.
- getDirUri(Configuration, Path) - Static method in class org.apache.hadoop.hbase.util.CommonFSUtils
-
Returns the URI in the string format
- getDispersionInformation() - Method in class org.apache.hadoop.hbase.master.AssignmentVerificationReport
-
Return a list which contains 3 elements: average dispersion score, max dispersion score and min dispersion score as first, second and third elements, respectively.
- getDNSServerType() - Method in class org.apache.hadoop.hbase.HBaseRpcServicesBase
- getDNSServerType() - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- getDNSServerType() - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
- getDoasFromHeader(HttpServletRequest) - Static method in class org.apache.hadoop.hbase.http.ProxyUserAuthenticationFilter
-
The purpose of this function is to get the doAs parameter of a http request case insensitively
- getDouble(String, double) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
- getDrainingRegionServers() - Method in interface org.apache.hadoop.hbase.master.MetricsMasterWrapper
-
Get the draining region servers
- getDrainingRegionServers() - Method in class org.apache.hadoop.hbase.master.MetricsMasterWrapperImpl
- getDrainingServersList() - Method in class org.apache.hadoop.hbase.master.ServerManager
-
Returns A copy of the internal list of draining servers.
- getDropDependentColumn() - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
- getDumpServlet() - Method in class org.apache.hadoop.hbase.HBaseServerBase
- getDumpServlet() - Method in class org.apache.hadoop.hbase.master.HMaster
- getDumpServlet() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
- getDurability() - Method in class org.apache.hadoop.hbase.client.Mutation
-
Get the current durability
- getDurability() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
Returns the durability setting for the table.
- getEarliestFlushTimeForAllStores() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
- getEarliestFlushTimeForAllStores() - Method in interface org.apache.hadoop.hbase.regionserver.Region
- getEarliestMemStoreSeqNum(byte[], byte[]) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
- getEarliestMemStoreSeqNum(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.wal.WAL
-
Gets the earliest unflushed sequence id in the memstore for the store.
- getEdit() - Method in class org.apache.hadoop.hbase.wal.WAL.Entry
-
Gets the edit
- getEditsRead() - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSource
- getEffectiveDataBlockEncoding() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
- getEffectiveEncodingInCache(boolean) - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
- getEffectiveEncodingInCache(boolean) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoder
- getEffectiveEncodingInCache(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoderImpl
- getEffectiveEncodingInCache(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
- getEffectiveEncodingInCache(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.NoOpDataBlockEncoder
- getEffectiveLevel(String) - Static method in class org.apache.hadoop.hbase.logging.Log4jUtils
- getEffectiveUser() - Method in class org.apache.hadoop.hbase.util.ConnectionCache
-
Get the current thread local effective user
- getElements() - Method in class org.apache.hadoop.hbase.util.LossyCounting
- getEligibleRequestsCount() - Method in class org.apache.hadoop.hbase.io.hfile.BloomFilterMetrics
-
Returns Current value for requests which could have used bloom filters but wasn't defined or loaded.
- getEnabled() - Method in class org.apache.hadoop.hbase.regionserver.BrokenStoreFileCleaner
- getEncodedCompressedSize(Compression.Algorithm, Compressor) - Method in class org.apache.hadoop.hbase.io.encoding.EncodedDataBlock
-
Estimate size after second stage of compression (e.g.
- getEncodedDataSizeWritten() - Method in class org.apache.hadoop.hbase.io.encoding.EncodingState
- getEncodedName() - Method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Returns the encoded region name.
- getEncodedNameAsBytes() - Method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Returns the encoded region name as an array of bytes.
- getEncodedNodeName(ZKWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog
-
Deprecated.Gets the full path node name for the log file being split.
- getEncodedPath() - Method in class org.apache.hadoop.hbase.regionserver.HStoreFile
- getEncodedPath() - Method in interface org.apache.hadoop.hbase.regionserver.StoreFile
-
Returns Encoded Path if this StoreFile was made with a Stream.
- getEncodedRegionName() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
-
Returns the region's encoded name.
- getEncodedRegionName() - Method in class org.apache.hadoop.hbase.replication.ZKReplicationQueueStorageForMigration.ZkLastPushedSeqId
- getEncodedRegionName() - Method in interface org.apache.hadoop.hbase.wal.WALKey
-
Returns encoded region name
- getEncodedRegionName() - Method in class org.apache.hadoop.hbase.wal.WALKeyImpl
-
Returns encoded region name
- getEncoder() - Method in enum class org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
-
Return new data block encoder for given algorithm type.
- getEncoder(OutputStream) - Method in class org.apache.hadoop.hbase.codec.CellCodec
- getEncoder(OutputStream) - Method in class org.apache.hadoop.hbase.codec.CellCodecWithTags
- getEncoder(OutputStream) - Method in interface org.apache.hadoop.hbase.codec.Codec
- getEncoder(OutputStream) - Method in class org.apache.hadoop.hbase.codec.KeyValueCodec
- getEncoder(OutputStream) - Method in class org.apache.hadoop.hbase.codec.KeyValueCodecWithTags
- getEncoder(OutputStream) - Method in class org.apache.hadoop.hbase.codec.MessageCodec
- getEncoder(OutputStream) - Method in class org.apache.hadoop.hbase.regionserver.wal.SecureWALCellCodec
- getEncoder(OutputStream) - Method in class org.apache.hadoop.hbase.regionserver.wal.WALCellCodec
- getEncodingById(short) - Static method in enum class org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
- getEncodingById(short) - Static method in enum class org.apache.hadoop.hbase.io.encoding.IndexBlockEncoding
- getEncodingCountsForTest() - Method in class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache
- getEncodingCountsForTest() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
- getEncodingState() - Method in class org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultEncodingContext
- getEncodingState() - Method in interface org.apache.hadoop.hbase.io.encoding.HFileBlockEncodingContext
-
Returns the encoding state
- getEncryptionContext() - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
- getEncryptionContext() - Method in class org.apache.hadoop.hbase.regionserver.StoreContext
- getEncryptionKey() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Returns Return the raw crypto key attribute for the family, or null if not set
- getEncryptionKey() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
- getEncryptionType() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Returns Return the encryption algorithm in use by this family
- getEncryptor() - Method in class org.apache.hadoop.hbase.io.crypto.aes.AES
- getEncryptor() - Method in class org.apache.hadoop.hbase.io.crypto.aes.CommonsCryptoAES
- getEncryptor() - Method in class org.apache.hadoop.hbase.io.crypto.Cipher
-
Get an encryptor for encrypting data.
- getEnd() - Method in exception org.apache.hadoop.hbase.errorhandling.TimeoutException
- getEndKey() - Method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Returns the endKey.
- getEndKey() - Method in class org.apache.hadoop.hbase.HbckRegionDetails
- getEndKey() - Method in class org.apache.hadoop.hbase.util.HbckRegionInfo
- getEndKey() - Method in interface org.apache.hadoop.hbase.util.KeyRange
- getEndKey() - Method in class org.apache.hadoop.hbase.util.MultiThreadedAction
-
Returns the end key of the key range, exclusive
- getEndKeyForDisplay(RegionInfo, Configuration) - Static method in class org.apache.hadoop.hbase.client.RegionInfoDisplay
-
Get the end key for display.
- getEndKeys() - Method in interface org.apache.hadoop.hbase.client.AsyncTableRegionLocator
-
Gets the ending row key for every region in the currently open table.
- getEndKeys() - Method in interface org.apache.hadoop.hbase.client.RegionLocator
-
Gets the ending row key for every region in the currently open table.
- getEndpointObserver() - Method in interface org.apache.hadoop.hbase.coprocessor.RegionCoprocessor
- getEndRow() - Method in class org.apache.hadoop.hbase.mapred.TableSplit
-
Returns end row key
- getEndRow() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
-
Returns the end row.
- getEndRow() - Method in class org.apache.hadoop.hbase.rest.RowSpec
- getEndRow(int) - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
- getEndTime() - Method in class org.apache.hadoop.hbase.rest.RowSpec
- getEntries() - Method in class org.apache.hadoop.hbase.io.HalfStoreFileReader
- getEntries() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
- getEntries() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
-
Returns number of KV entries in this HFile
- getEntries() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileReader
- getEntries() - Method in class org.apache.hadoop.hbase.replication.ReplicationEndpoint.ReplicateContext
- getEntry() - Method in class org.apache.hadoop.hbase.client.SingleResponse
- getEntry() - Method in class org.apache.hadoop.hbase.wal.WALTailingReader.Result
- getEntry(short) - Method in interface org.apache.hadoop.hbase.io.util.Dictionary
-
Gets an entry from the dictionary.
- getEntry(short) - Method in class org.apache.hadoop.hbase.io.util.LRUDictionary
- getEntryBySubEntry(long) - Method in interface org.apache.hadoop.hbase.io.hfile.BlockIndexChunk
- getEntryCount() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
- getEntryEndPos() - Method in class org.apache.hadoop.hbase.wal.WALTailingReader.Result
- getEnum(String, T) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
- getEnvironment() - Method in interface org.apache.hadoop.hbase.coprocessor.ObserverContext
- getEnvironment() - Method in class org.apache.hadoop.hbase.coprocessor.ObserverContextImpl
- getErasureCodingPolicy() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
The HDFS erasure coding policy for a table.
- getErrorHandler() - Method in class org.apache.hadoop.hbase.ipc.RpcServer
- getErrorHandler() - Method in interface org.apache.hadoop.hbase.ipc.RpcServerInterface
- getErrorList() - Method in interface org.apache.hadoop.hbase.util.HbckErrorReporter
-
Deprecated.
- getErrorRate(Configuration) - Static method in class org.apache.hadoop.hbase.util.BloomFilterFactory
-
Returns the Bloom filter error rate in the given configuration
- getErrors() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- getEstimatedNumberOfKvsScanned() - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
Returns The estimated number of KVs seen by this scanner (includes some skipped KVs).
- getEvent() - Method in class org.apache.hadoop.hbase.namequeues.impl.BalancerDecisionQueueService
- getEvent() - Method in class org.apache.hadoop.hbase.namequeues.impl.BalancerRejectionQueueService
- getEvent() - Method in class org.apache.hadoop.hbase.namequeues.impl.SlowLogQueueService
- getEvent() - Method in interface org.apache.hadoop.hbase.namequeues.NamedQueueService
-
Retrieve event type for NamedQueueService implementation.
- getEvent() - Method in class org.apache.hadoop.hbase.namequeues.WALEventTrackerQueueService
- getEventByOrdinal(int) - Static method in enum class org.apache.hadoop.hbase.namequeues.NamedQueuePayload.NamedQueueEvent
- getEventLoopGroupConfig() - Method in class org.apache.hadoop.hbase.HBaseServerBase
- getEventType() - Method in class org.apache.hadoop.hbase.regionserver.FlushRegionCallable
- getEventType() - Method in class org.apache.hadoop.hbase.regionserver.SnapshotRegionCallable
- getEventType() - Method in class org.apache.hadoop.hbase.regionserver.SnapshotVerifyCallable
- getEventType() - Method in class org.apache.hadoop.hbase.regionserver.SplitWALCallable
- getEvictCount() - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerContext
- getEvictedBlocks() - Method in class org.apache.hadoop.hbase.CacheEvictionStats
- getEvictedCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
- getEvictedCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
- getEvictedFileCount() - Method in class org.apache.hadoop.hbase.mob.MobFileCache
-
Gets the number of items evicted from the mob file cache.
- getEvictionCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
- getEvictionCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
- getExceedThrottleQuotaRowKey() - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
- getException() - Method in class org.apache.hadoop.hbase.errorhandling.ForeignExceptionDispatcher
- getException() - Method in interface org.apache.hadoop.hbase.errorhandling.ForeignExceptionSnare
-
Get the value of the captured exception.
- getException() - Method in class org.apache.hadoop.hbase.zookeeper.DeletionListener
-
Get the last exception which has occurred when re-setting the watch.
- getException(byte[]) - Method in class org.apache.hadoop.hbase.client.MultiResponse
-
Returns the exception for the region, if any.
- getExceptionCount() - Method in class org.apache.hadoop.hbase.CacheEvictionStats
- getExceptionIfFailed() - Method in interface org.apache.hadoop.hbase.master.SnapshotSentinel
-
Get the exception that caused the snapshot to fail, if the snapshot has failed.
- getExceptionMsg() - Method in class org.apache.hadoop.hbase.regionserver.OperationStatus
- getExceptions() - Method in class org.apache.hadoop.hbase.CacheEvictionStats
- getExceptions() - Method in class org.apache.hadoop.hbase.client.MultiResponse
- getExcludeDatanodeManager() - Method in class org.apache.hadoop.hbase.io.asyncfs.monitor.StreamSlowMonitor
- getExcludeDatanodeManager() - Method in class org.apache.hadoop.hbase.wal.WALFactory
- getExcludeDNs() - Method in class org.apache.hadoop.hbase.io.asyncfs.monitor.ExcludeDatanodeManager
- getExcludeNamespaces() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
- getExcludeTableCFsMap() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
- getExecString() - Method in class org.apache.hadoop.hbase.chaos.ChaosAgent.LocalShell
- getExecutor() - Method in interface org.apache.hadoop.metrics2.MetricsExecutor
- getExecutorService() - Method in class org.apache.hadoop.hbase.HBaseServerBase
- getExecutorService() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Returns Master's instance of
ExecutorService
- getExecutorService() - Method in class org.apache.hadoop.hbase.MockRegionServerServices
- getExecutorService() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
Returns hbase executor service
- getExecutorStatus(String) - Method in class org.apache.hadoop.hbase.ExecutorStatusChore
- getExhaustiveDescription() - Method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
- getExistingAssignmentPlan() - Method in class org.apache.hadoop.hbase.master.SnapshotOfRegionAssignmentFromMeta
-
Get the favored nodes plan
- getExists() - Method in class org.apache.hadoop.hbase.client.Result
- getExistsResource() - Method in class org.apache.hadoop.hbase.rest.TableResource
- getExtendedAttribute(String) - Method in interface org.apache.hadoop.hbase.wal.WALKey
-
Return a named String value injected into the WALKey during processing, such as by a coprocessor
- getExtendedAttribute(String) - Method in class org.apache.hadoop.hbase.wal.WALKeyImpl
- getExtendedAttributes() - Method in interface org.apache.hadoop.hbase.wal.WALKey
-
Returns a map of all extended attributes injected into this WAL key.
- getExtendedAttributes() - Method in class org.apache.hadoop.hbase.wal.WALKeyImpl
- getExtendedCells(WALEdit) - Static method in class org.apache.hadoop.hbase.wal.WALEditInternalHelper
- getExtendedFamilyCellMap(Mutation) - Static method in class org.apache.hadoop.hbase.client.ClientInternalHelper
- getExtendedRawCells(Result) - Static method in class org.apache.hadoop.hbase.client.ClientInternalHelper
- getExternalDfsUri() - Method in class org.apache.hadoop.hbase.testing.TestingHBaseClusterOption
- getExternalZkConnectString() - Method in class org.apache.hadoop.hbase.testing.TestingHBaseClusterOption
- getExtraHeader(String) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Get an extra header value.
- getExtraHeaders() - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Get all extra headers (read-only).
- getFactoryId() - Method in class org.apache.hadoop.hbase.wal.WALFactory
- getFailed() - Method in class org.apache.hadoop.hbase.client.ClientCoprocessorRpcController
- getFailed() - Method in class org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
- getFailed() - Method in interface org.apache.hadoop.hbase.ipc.HBaseRpcController
-
Return the failed exception, null if not failed.
- getFailed() - Method in class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
- getFailedCounter() - Method in class org.apache.hadoop.hbase.metrics.OperationMetrics
- getFailedDeletions() - Method in class org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination.SplitLogManagerDetails
-
Deprecated.Returns a set of failed deletions
- getFailedFiles() - Method in exception org.apache.hadoop.hbase.backup.FailedArchiveException
- getFailedIncrements() - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
- getFailedIncrements() - Method in interface org.apache.hadoop.hbase.thrift.IncrementCoalescerMBean
- getFailedInserts() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
- getFailedInserts() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
- getFailedMsg() - Method in class org.apache.hadoop.hbase.backup.BackupInfo
- getFailedOn() - Method in class org.apache.hadoop.hbase.ipc.ServerRpcController
-
Returns any exception thrown during service method invocation, or
null
if no exception was thrown. - getFailedPuts() - Method in interface org.apache.hadoop.hbase.namequeues.MetricsWALEventTrackerSource
- getFailedPuts() - Method in class org.apache.hadoop.hbase.namequeues.MetricsWALEventTrackerSourceImpl
- getFailedServersFromLogFolders() - Method in class org.apache.hadoop.hbase.master.MasterWalManager
-
Deprecated.With proc-v2, we can record the crash server with procedure store, so do not need to scan the wal directory to find out the splitting wal directory any more. Leave it here only because
RecoverMetaProcedure
(which is also deprecated) uses it. - getFailureCount() - Method in exception org.apache.hadoop.hbase.exceptions.PreemptiveFastFailException
-
Deprecated.Returns failure count
- getFailureMobFiles() - Method in class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
-
Returns the set of check failure mob file paths after checkTables is called.
- getFailures() - Method in class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
-
Returns the set of check failure file paths after checkTables is called.
- getFamilies() - Method in class org.apache.hadoop.hbase.client.ImmutableScan
- getFamilies() - Method in class org.apache.hadoop.hbase.client.Scan
-
Returns the keys of the familyMap
- getFamilies() - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
Returns the set of families present on disk n
- getFamilies() - Method in class org.apache.hadoop.hbase.wal.WALEdit
-
For use by FSWALEntry ONLY.
- getFamily() - Method in class org.apache.hadoop.hbase.client.CheckAndMutate
-
Returns the family to check
- getFamily() - Method in class org.apache.hadoop.hbase.filter.ColumnValueFilter
-
Returns the column family
- getFamily() - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
-
Returns the column family
- getFamily() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
Returns the family
- getFamily() - Method in class org.apache.hadoop.hbase.regionserver.ScanInfo
- getFamily() - Method in class org.apache.hadoop.hbase.regionserver.StoreContext
- getFamily(int) - Method in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
- getFamilyArray() - Method in class org.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValue
- getFamilyArray() - Method in class org.apache.hadoop.hbase.ByteBufferKeyValue
- getFamilyArray() - Method in interface org.apache.hadoop.hbase.Cell
-
Contiguous bytes composed of legal HDFS filename characters which may start at any index in the containing array.
- getFamilyArray() - Method in class org.apache.hadoop.hbase.IndividualBytesFieldCell
- getFamilyArray() - Method in class org.apache.hadoop.hbase.KeyValue
-
Returns the backing array of the entire KeyValue (all KeyValue fields are in a single array)
- getFamilyArray() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
- getFamilyArray() - Method in class org.apache.hadoop.hbase.util.MapReduceExtendedCell
- getFamilyByteBuffer() - Method in class org.apache.hadoop.hbase.ByteBufferExtendedCell
-
Returns The
ByteBuffer
containing the column family bytes. - getFamilyByteBuffer() - Method in class org.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValue
- getFamilyByteBuffer() - Method in class org.apache.hadoop.hbase.ByteBufferKeyValue
- getFamilyByteBuffer() - Method in class org.apache.hadoop.hbase.util.MapReduceExtendedCell
- getFamilyCellMap() - Method in class org.apache.hadoop.hbase.client.Mutation
-
Method for retrieving the put's familyMap
- getFamilyDirs(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Given a particular region dir, return all the familydirs inside it
- getFamilyLength() - Method in class org.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValue
- getFamilyLength() - Method in class org.apache.hadoop.hbase.ByteBufferKeyValue
- getFamilyLength() - Method in interface org.apache.hadoop.hbase.Cell
-
Returns Number of family bytes.
- getFamilyLength() - Method in class org.apache.hadoop.hbase.IndividualBytesFieldCell
- getFamilyLength() - Method in class org.apache.hadoop.hbase.KeyValue
-
Returns Family length
- getFamilyLength() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
- getFamilyLength() - Method in class org.apache.hadoop.hbase.util.MapReduceExtendedCell
- getFamilyLength(int) - Method in class org.apache.hadoop.hbase.KeyValue
-
Returns Family length
- getFamilyMap() - Method in class org.apache.hadoop.hbase.client.Get
-
Method for retrieving the get's familyMap
- getFamilyMap() - Method in class org.apache.hadoop.hbase.client.ImmutableScan
- getFamilyMap() - Method in class org.apache.hadoop.hbase.client.Scan
-
Getting the familyMap
- getFamilyMap(byte[]) - Method in class org.apache.hadoop.hbase.client.Result
-
Map of qualifiers to values.
- getFamilyMapOfLongs() - Method in class org.apache.hadoop.hbase.client.Increment
-
Before 0.95, when you called Increment#getFamilyMap(), you got back a map of families to a list of Longs.
- getFamilyName() - Method in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
- getFamilyOffset() - Method in class org.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValue
- getFamilyOffset() - Method in class org.apache.hadoop.hbase.ByteBufferKeyValue
- getFamilyOffset() - Method in interface org.apache.hadoop.hbase.Cell
-
Returns Array index of first family byte
- getFamilyOffset() - Method in class org.apache.hadoop.hbase.IndividualBytesFieldCell
- getFamilyOffset() - Method in class org.apache.hadoop.hbase.KeyValue
-
Returns Family offset
- getFamilyOffset() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
- getFamilyOffset() - Method in class org.apache.hadoop.hbase.util.MapReduceExtendedCell
- getFamilyPosition() - Method in class org.apache.hadoop.hbase.ByteBufferExtendedCell
-
Returns Position in the
ByteBuffer
where column family bytes start - getFamilyPosition() - Method in class org.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValue
- getFamilyPosition() - Method in class org.apache.hadoop.hbase.ByteBufferKeyValue
- getFamilyPosition() - Method in class org.apache.hadoop.hbase.util.MapReduceExtendedCell
- getFamilyPosition(int) - Method in class org.apache.hadoop.hbase.ByteBufferKeyValue
- getFamilyStoreDirectoryPath() - Method in class org.apache.hadoop.hbase.regionserver.StoreContext
- getFamilyString(KeyValue) - Static method in class org.apache.hadoop.hbase.KeyValueTestUtil
- getFavoredNodeList(String) - Static method in class org.apache.hadoop.hbase.master.RegionPlacementMaintainer
- getFavoredNodes() - Method in class org.apache.hadoop.hbase.regionserver.StoreContext
- getFavoredNodes(List<ServerName>) - Static method in class org.apache.hadoop.hbase.favored.FavoredNodeAssignmentHelper
-
Returns PB'ed bytes of
HBaseProtos.FavoredNodes
generated by the server list. - getFavoredNodes(RegionInfo) - Method in class org.apache.hadoop.hbase.favored.FavoredNodeLoadBalancer
- getFavoredNodes(RegionInfo) - Method in class org.apache.hadoop.hbase.favored.FavoredNodesManager
- getFavoredNodes(RegionInfo) - Method in class org.apache.hadoop.hbase.favored.FavoredNodesPlan
-
Returns the list of favored region server for this region based on the plan
- getFavoredNodes(RegionInfo) - Method in interface org.apache.hadoop.hbase.favored.FavoredNodesPromoter
- getFavoredNodesAsString(List<ServerName>) - Static method in class org.apache.hadoop.hbase.favored.FavoredNodeAssignmentHelper
- getFavoredNodesForRegion(String) - Method in class org.apache.hadoop.hbase.MockRegionServerServices
- getFavoredNodesForRegion(String) - Method in interface org.apache.hadoop.hbase.regionserver.FavoredNodesForRegion
-
Get the favored nodes mapping for this region.
- getFavoredNodesForRegion(String) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Return the favored nodes for a region given its encoded name.
- getFavoredNodesList(byte[]) - Static method in class org.apache.hadoop.hbase.favored.FavoredNodeAssignmentHelper
-
Convert PB bytes to ServerName.
- getFavoredNodesManager() - Method in class org.apache.hadoop.hbase.master.HMaster
- getFavoredNodesManager() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Returns Favored Nodes Manager
- getFavoredNodesManager() - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupBasedLoadBalancer
- getFavoredNodesWithDNPort(RegionInfo) - Method in class org.apache.hadoop.hbase.favored.FavoredNodesManager
-
This should only be used when sending FN information to the region servers.
- getFavoredServerPosition(List<ServerName>, ServerName) - Static method in class org.apache.hadoop.hbase.favored.FavoredNodesPlan
-
Return the position of the server in the favoredNodes list.
- getField() - Method in class org.apache.hadoop.hbase.hbtop.field.FieldInfo
- getField() - Method in class org.apache.hadoop.hbase.hbtop.RecordFilter
- getField() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.Header
- getFieldInfos() - Method in class org.apache.hadoop.hbase.hbtop.mode.ClientModeStrategy
- getFieldInfos() - Method in enum class org.apache.hadoop.hbase.hbtop.mode.Mode
- getFieldInfos() - Method in class org.apache.hadoop.hbase.hbtop.mode.NamespaceModeStrategy
- getFieldInfos() - Method in class org.apache.hadoop.hbase.hbtop.mode.RegionModeStrategy
- getFieldInfos() - Method in class org.apache.hadoop.hbase.hbtop.mode.RegionServerModeStrategy
- getFieldInfos() - Method in class org.apache.hadoop.hbase.hbtop.mode.TableModeStrategy
- getFieldInfos() - Method in class org.apache.hadoop.hbase.hbtop.mode.UserModeStrategy
- getFieldInfos() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenModel
- getFields() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenModel
- getFieldValueType() - Method in enum class org.apache.hadoop.hbase.hbtop.field.Field
- getFifteenMinuteRate() - Method in interface org.apache.hadoop.hbase.metrics.Meter
-
Returns the fifteen-minute exponentially-weighted moving average rate at which events have occurred since the meter was created.
- getFile(String, String) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
- getFileContext() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
-
Return the file context of the HFile this reader belongs to
- getFileContext() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Writer
-
Return the file context for the HFile this writer belongs to
- getFileContext() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
- getFileContext() - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterImpl
- getFileCreateTime() - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
- getFileInfo() - Method in class org.apache.hadoop.hbase.regionserver.HStoreFile
- getFileInfoHitCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
- getFileInfoHitCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
- getFileInfoHitCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
- getFileInfoMissCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
- getFileInfoMissCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
- getFileInfoMissCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
- getFileInfoOffset() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
- getFileList(Configuration, List<Path>, PathFilter) - Static method in class org.apache.hadoop.hbase.master.SplitLogManager
-
Deprecated.Get a list of paths that need to be split given a set of server-specific directories and optionally a filter.
- getFilename() - Method in interface org.apache.hadoop.hbase.io.hfile.CachedBlock
- getFileName() - Method in class org.apache.hadoop.hbase.mob.MobFile
-
Gets the file name.
- getFileName() - Method in class org.apache.hadoop.hbase.mob.MobFileName
-
Gets the file name.
- getFileName(String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog
-
Deprecated.
- getFilenum() - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
- getFileNumFromFileName(Path) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
A log file has a creation timestamp (in ms) in its file name (
AbstractFSWAL.filenum
. - getFilePath() - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheKey
- getFilePath() - Method in class org.apache.hadoop.hbase.io.hfile.ReaderContext
- getFilePath() - Method in interface org.apache.hadoop.hbase.regionserver.KeyValueScanner
- getFilePath() - Method in class org.apache.hadoop.hbase.regionserver.NonLazyKeyValueScanner
- getFilePath() - Method in class org.apache.hadoop.hbase.regionserver.SegmentScanner
- getFilePath() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
- getFilePermissions(FileSystem, Configuration, String) - Static method in class org.apache.hadoop.hbase.util.CommonFSUtils
-
Get the file permissions specified in the configuration, if they are enabled.
- getFileRegion() - Method in class org.apache.hadoop.hbase.io.Reference
- getFilesForScan(byte[], boolean, byte[], boolean, boolean) - Method in interface org.apache.hadoop.hbase.regionserver.StoreFileManager
-
Gets the store files to scan for a Scan or Get request.
- getFilesForScan(byte[], boolean, byte[], boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
- getFileSize() - Method in class org.apache.hadoop.hbase.io.hfile.ReaderContext
- getFileStatus() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
Returns The
FileStatus
of the file - getFileStatus(FileSystem) - Method in class org.apache.hadoop.hbase.io.FileLink
-
Get the FileStatus of the referenced file.
- getFilesystem() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Returns
FileSystem
being used by this region - getFilesystem() - Method in class org.apache.hadoop.hbase.replication.ReplicationEndpoint.Context
- getFileSystem() - Method in class org.apache.hadoop.hbase.HBaseServerBase
- getFileSystem() - Method in class org.apache.hadoop.hbase.io.hfile.ReaderContext
- getFileSystem() - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
- getFileSystem() - Method in class org.apache.hadoop.hbase.master.MasterWalManager
- getFileSystem() - Method in class org.apache.hadoop.hbase.MockRegionServerServices
- getFileSystem() - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
Returns the underlying
FileSystem
- getFileSystem() - Method in class org.apache.hadoop.hbase.regionserver.HStore
- getFileSystem() - Method in interface org.apache.hadoop.hbase.regionserver.Store
- getFileSystem() - Method in interface org.apache.hadoop.hbase.Server
-
Returns Return the FileSystem object used (can return null!).
- getFilter() - Method in class org.apache.hadoop.hbase.client.CheckAndMutate
-
Returns the filter to check
- getFilter() - Method in class org.apache.hadoop.hbase.client.ImmutableScan
- getFilter() - Method in class org.apache.hadoop.hbase.client.Query
- getFilter() - Method in class org.apache.hadoop.hbase.client.Scan
-
Returns RowFilter
- getFilter() - Method in class org.apache.hadoop.hbase.filter.SkipFilter
- getFilter() - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
- getFilter() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.CompactionScanQueryMatcher
- getFilter() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher
-
Returns the Filter
- getFilter() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.UserScanQueryMatcher
- getFilterArguments(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Returns the arguments of the filter from the filter string
- getFilterByOperator() - Method in class org.apache.hadoop.hbase.client.LogQueryFilter
-
Deprecated.
- getFilterConfigMap(Configuration, String) - Static method in class org.apache.hadoop.hbase.http.lib.AuthenticationFilterInitializer
- getFilteredLogs(AdminProtos.SlowLogResponseRequest, List<TooSlowLog.SlowLogPayload>) - Static method in class org.apache.hadoop.hbase.namequeues.LogHandlerUtils
- getFilteredReadRequestCount() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
Returns the number of filtered read requests made to region
- getFilteredReadRequestCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
-
Get the total number of filtered read requests that have been issued against this region
- getFilteredReadRequestCount() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
- getFilteredReadRequestCount(String) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregate
-
Get the total number of filtered read requests that have been issued against this table
- getFilteredReadRequestCount(String) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImpl
- getFilteredReadRequestCountPerSecond() - Method in class org.apache.hadoop.hbase.hbtop.mode.RequestCountPerSecond
- getFilteredReadRequests() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsUserSource.ClientMetrics
- getFilteredReadRequests() - Method in interface org.apache.hadoop.hbase.UserMetrics
-
Returns count of filtered read requests for a user
- getFilteredReadRequestsCount() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
- getFilteredReadRequestsCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the number of filtered read requests to regions hosted on this region server.
- getFilteredReadRequestsCount() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Returns filtered read requests count for this region
- getFilteredReadRequestsCount() - Method in interface org.apache.hadoop.hbase.UserMetrics.ClientMetrics
- getFilteredReadRequestsCount() - Method in class org.apache.hadoop.hbase.UserMetricsBuilder.ClientMetricsImpl
- getFilterEntries() - Method in class org.apache.hadoop.hbase.io.HalfStoreFileReader
- getFilterEntries() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileReader
-
The number of Bloom filter entries in this store file, or an estimate thereof, if the Bloom filter is not loaded.
- getFilterHistories() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenModel
- getFilterIfMissing() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
Get whether entire row should be filtered if column is not found.
- getFilterName(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Returns the filter name given a simple filter expression
- getFilters() - Method in class org.apache.hadoop.hbase.filter.FilterList
-
Get the filters.
- getFilters() - Method in class org.apache.hadoop.hbase.filter.FilterListBase
- getFilters() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenModel
- getFinalFunctionCosts() - Method in class org.apache.hadoop.hbase.client.BalancerDecision
- getFinalParameters() - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
- getFingerprint() - Method in class org.apache.hadoop.hbase.client.Get
-
Compile the table and column family (i.e.
- getFingerprint() - Method in class org.apache.hadoop.hbase.client.ImmutableScan
- getFingerprint() - Method in class org.apache.hadoop.hbase.client.Mutation
-
Compile the column family (i.e.
- getFingerprint() - Method in class org.apache.hadoop.hbase.client.Operation
-
Produces a Map containing a fingerprint which identifies the type and the static schema components of a query (i.e.
- getFingerprint() - Method in class org.apache.hadoop.hbase.client.Scan
-
Compile the table and column family (i.e.
- getFirst() - Method in class org.apache.hadoop.hbase.util.ObjectIntPair
- getFirst() - Method in class org.apache.hadoop.hbase.util.Pair
-
Return the first element stored in the pair.
- getFirst() - Method in class org.apache.hadoop.hbase.util.PairOfSameType
-
Return the first element stored in the pair.
- getFirst() - Method in class org.apache.hadoop.hbase.util.Triple
- getFirst(TNode) - Static method in class org.apache.hadoop.hbase.util.AvlUtil.AvlTree
-
Return the first node of the tree.
- getFirstDataBlockOffset() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
- getFirstFailureAt() - Method in exception org.apache.hadoop.hbase.exceptions.PreemptiveFastFailException
-
Deprecated.Returns time of the fist failure
- getFirstKey() - Method in class org.apache.hadoop.hbase.io.HalfStoreFileReader
- getFirstKey() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
- getFirstKey() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
- getFirstKey() - Method in class org.apache.hadoop.hbase.regionserver.HStoreFile
- getFirstKey() - Method in interface org.apache.hadoop.hbase.regionserver.StoreFile
-
Get the first key in this store file.
- getFirstKey() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileReader
- getFirstKeyCellInBlock(HFileBlock) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.EncodedScanner
- getFirstKeyCellInBlock(HFileBlock) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
- getFirstKeyCellInBlock(ByteBuff) - Method in class org.apache.hadoop.hbase.io.encoding.CopyKeyDataBlockEncoder
- getFirstKeyCellInBlock(ByteBuff) - Method in interface org.apache.hadoop.hbase.io.encoding.DataBlockEncoder
-
Return first key in block as a cell.
- getFirstKeyCellInBlock(ByteBuff) - Method in class org.apache.hadoop.hbase.io.encoding.DiffKeyDeltaEncoder
- getFirstKeyCellInBlock(ByteBuff) - Method in class org.apache.hadoop.hbase.io.encoding.FastDiffDeltaEncoder
- getFirstKeyCellInBlock(ByteBuff) - Method in class org.apache.hadoop.hbase.io.encoding.PrefixKeyDeltaEncoder
- getFirstKeyCellInBlock(ByteBuff) - Method in class org.apache.hadoop.hbase.io.encoding.RowIndexCodecV1
- getFirstLevelCache() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
- getFirstRowKey() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
- getFirstRowKey() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
-
TODO left from
HFile
version 1: move this to StoreFile after Ryan's patch goes in to eliminateKeyValue
here. - getFiveMinuteRate() - Method in interface org.apache.hadoop.hbase.metrics.Meter
-
Returns the five-minute exponentially-weighted moving average rate at which events have occurred since the meter was created.
- getFlattenAction() - Method in class org.apache.hadoop.hbase.regionserver.AdaptiveMemStoreCompactionStrategy
- getFlattenAction() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreCompactionStrategy
- getFloat(String, float) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
- getFlushableSize() - Method in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
- getFlushableSize() - Method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore
- getFlushableSize() - Method in class org.apache.hadoop.hbase.regionserver.HStore
- getFlushableSize() - Method in interface org.apache.hadoop.hbase.regionserver.MemStore
-
Flush will first clear out the data in snapshot if any (It will take a second flush invocation to clear the current Cell set).
- getFlushableSize() - Method in interface org.apache.hadoop.hbase.regionserver.Store
- getFlushDescriptor(Cell) - Static method in class org.apache.hadoop.hbase.wal.WALEdit
- getFlushedCellsCount() - Method in class org.apache.hadoop.hbase.regionserver.HStore
- getFlushedCellsCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the number of cells flushed to disk.
- getFlushedCellsCount() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Returns The number of cells flushed to disk
- getFlushedCellsSize() - Method in class org.apache.hadoop.hbase.regionserver.HStore
- getFlushedCellsSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the total amount of data flushed to disk, in bytes.
- getFlushedCellsSize() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Returns The total size of data flushed to disk, in bytes
- getFlushedOutputFileSize() - Method in class org.apache.hadoop.hbase.regionserver.HStore
- getFlushedOutputFileSize() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Returns The total size of out output files on disk, in bytes
- getFlushedSequenceIdByRegion() - Method in class org.apache.hadoop.hbase.master.ServerManager
- getFlusherCount() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreFlusher
- getFlushPolicyClass(TableDescriptor, Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.FlushPolicyFactory
-
Get FlushPolicy class for the given table.
- getFlushPolicyClassName() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
This gets the class associated with the flush policy which determines the stores need to be flushed when flushing a region.
- getFlushPressure() - Method in class org.apache.hadoop.hbase.MockRegionServerServices
- getFlushPressure() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
- getFlushPressure() - Method in class org.apache.hadoop.hbase.regionserver.RegionServerAccounting
- getFlushPressure() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
Deprecated.
- getFlushQueueSize() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreFlusher
- getFlushQueueSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the size of the flush queue.
- getFlushRequester() - Method in class org.apache.hadoop.hbase.MockRegionServerServices
- getFlushRequester() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Returns reference to FlushRequester
- getFlushRequester() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
- getFlushThroughputController() - Method in class org.apache.hadoop.hbase.MockRegionServerServices
- getFlushThroughputController() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
- getFlushThroughputController() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
Returns the controller to avoid flush too fast
- getForegroundColor() - Method in class org.apache.hadoop.hbase.hbtop.terminal.Attributes
- getForegroundColor() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.Cell
- getFormatVersion(Configuration) - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
- getFreeBufferCount() - Method in class org.apache.hadoop.hbase.io.ByteBuffAllocator
-
The
ConcurrentLinkedQueue.size()
is O(N) complexity and time-consuming, so DO NOT use the method except in UT. - getFreeMemory() - Method in class org.apache.hadoop.hbase.util.JVM
-
Return the physical free memory (not the JVM one, as it's not very useful as it depends on the GC), but the one from the OS as it allows a little bit more to guess if the machine is overloaded or not).
- getFreeSize() - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCache
-
Returns the free size of the block cache, in bytes.
- getFreeSize() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
- getFreeSize() - Method in class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache
- getFreeSize() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
- getFreeSize() - Method in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
- getFreeSize() - Method in class org.apache.hadoop.hbase.io.hfile.TinyLfuBlockCache
- getFromCacheOrFetch() - Method in class org.apache.hadoop.hbase.master.CachedClusterId
-
Fetches the ClusterId from FS if it is not cached locally.
- getFromStoreFile(HStore, byte[], NavigableSet<byte[]>) - Static method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Do a small get/scan against one store.
- getFromStoreFile(HStore, Get) - Static method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Do a small get/scan against one store.
- getFromTables() - Method in class org.apache.hadoop.hbase.backup.RestoreRequest
- getFsReadTime() - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord
- getFsReadTime() - Method in interface org.apache.hadoop.hbase.ipc.RpcCall
- getFsReadTime() - Method in class org.apache.hadoop.hbase.ipc.ServerCall
- getFsReadTime() - Method in class org.apache.hadoop.hbase.namequeues.RpcLogDetails
- getFullyCachedFiles() - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCache
-
Returns an Optional containing the map of files that have been fully cached (all its blocks are present in the cache.
- getFullyCachedFiles() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
-
Returns the list of fully cached files
- getFuzzyKeys() - Method in class org.apache.hadoop.hbase.filter.FuzzyRowFilter
-
Returns the Fuzzy keys in the format expected by the constructor.
- getGcCollectorBeans() - Static method in class org.apache.hadoop.hbase.util.JSONMetricUtil
- getGeneralBloomFilterMetadata() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
-
Retrieves general Bloom filter metadata as appropriate for each
HFile
version. - getGeneralBloomFilterMetadata() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
-
Returns a buffer with the Bloom filter metadata.
- getGeneralBloomMetaHitCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
- getGeneralBloomMetaHitCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
- getGeneralBloomMetaHitCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
- getGeneralBloomMetaMissCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
- getGeneralBloomMetaMissCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
- getGeneralBloomMetaMissCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
- getGeneralQueueLength() - Method in class org.apache.hadoop.hbase.ipc.DelegatingRpcScheduler
- getGeneralQueueLength() - Method in class org.apache.hadoop.hbase.ipc.FifoRpcScheduler
- getGeneralQueueLength() - Method in class org.apache.hadoop.hbase.ipc.MasterFifoRpcScheduler
- getGeneralQueueLength() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapper
- getGeneralQueueLength() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapperImpl
- getGeneralQueueLength() - Method in class org.apache.hadoop.hbase.ipc.RpcScheduler
-
Retrieves length of the general queue for metrics.
- getGeneralQueueLength() - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
- getGetRegionInfoRequest(byte[]) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Returns A GetRegionInfoRequest for the passed in regionName.
- getGetTracker() - Method in class org.apache.hadoop.hbase.client.MetricsConnection
-
getTracker metric
- getGlobalLimiter() - Method in class org.apache.hadoop.hbase.quotas.QuotaState
-
Return the limiter associated with this quota.
- getGlobalMemStoreDataSize() - Method in class org.apache.hadoop.hbase.regionserver.RegionServerAccounting
-
Returns the global Memstore data size in the RegionServer
- getGlobalMemStoreHeapLowerMark(Configuration, boolean) - Static method in class org.apache.hadoop.hbase.io.util.MemorySizeUtil
-
Retrieve configured size for global memstore lower water mark as fraction of global memstore size.
- getGlobalMemStoreHeapPercent(Configuration, boolean) - Static method in class org.apache.hadoop.hbase.io.util.MemorySizeUtil
-
Retrieve global memstore configured size as percentage of total heap.
- getGlobalMemStoreHeapSize() - Method in class org.apache.hadoop.hbase.regionserver.RegionServerAccounting
-
Returns the global memstore on-heap size in the RegionServer
- getGlobalMemStoreOffHeapSize() - Method in class org.apache.hadoop.hbase.regionserver.RegionServerAccounting
-
Returns the global memstore off-heap size in the RegionServer
- getGlobalMemStoreSize(Configuration) - Static method in class org.apache.hadoop.hbase.io.util.MemorySizeUtil
-
Returns Pair of global memstore size and memory type(ie.
- getGroupName(String) - Static method in class org.apache.hadoop.hbase.AuthUtil
-
Deprecated.Returns the actual name for a group principal (stripped of the group prefix).
- getGroupNames() - Method in class org.apache.hadoop.hbase.security.User
-
Returns the list of groups of which this user is a member.
- getGroupNames() - Method in class org.apache.hadoop.hbase.security.User.SecureHadoopUser
- getGroups() - Static method in class org.apache.hadoop.hbase.security.UserProvider
- getGroups(String) - Method in class org.apache.hadoop.hbase.security.User.TestingGroups
- getHandler(String, double, int, BlockingQueue<CallRunner>, AtomicInteger, AtomicInteger, Abortable) - Method in class org.apache.hadoop.hbase.ipc.FastPathBalancedQueueRpcExecutor
- getHandler(String, double, int, BlockingQueue<CallRunner>, AtomicInteger, AtomicInteger, Abortable) - Method in class org.apache.hadoop.hbase.ipc.FastPathRWQueueRpcExecutor
- getHandler(String, double, int, BlockingQueue<CallRunner>, AtomicInteger, AtomicInteger, Abortable) - Method in class org.apache.hadoop.hbase.ipc.RpcExecutor
-
Override if providing alternate Handler implementation.
- getHashCount() - Method in class org.apache.hadoop.hbase.util.BloomFilterChunk
- getHashType() - Method in class org.apache.hadoop.hbase.util.BloomFilterChunk
- getHashType(Configuration) - Static method in class org.apache.hadoop.hbase.util.Hash
-
This utility method converts the name of the configured hash type to a symbolic constant.
- getHBaseCluster() - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Get the Mini HBase cluster.
- getHBaseClusterInterface() - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Returns the HBaseCluster instance.
- getHBaseServerWrapper() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServer
- getHBaseVersion() - Method in interface org.apache.hadoop.hbase.ClusterMetrics
-
Returns the HBase version string as reported by the HMaster
- getHBaseVersion() - Method in class org.apache.hadoop.hbase.coprocessor.BaseEnvironment
-
Returns the HBase release
- getHBaseVersion() - Method in interface org.apache.hadoop.hbase.CoprocessorEnvironment
-
Returns the HBase version as a string (e.g.
- getHbck() - Method in interface org.apache.hadoop.hbase.client.AsyncConnection
-
Retrieve an Hbck implementation to fix an HBase cluster.
- getHbck() - Method in class org.apache.hadoop.hbase.client.AsyncConnectionImpl
- getHbck() - Method in interface org.apache.hadoop.hbase.client.Connection
-
Retrieve an Hbck implementation to fix an HBase cluster.
- getHbck() - Method in class org.apache.hadoop.hbase.client.SharedAsyncConnection
- getHbck() - Method in class org.apache.hadoop.hbase.client.SharedConnection
- getHbck() - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Returns an
Hbck
instance. - getHbck(ServerName) - Method in interface org.apache.hadoop.hbase.client.AsyncConnection
-
Retrieve an Hbck implementation to fix an HBase cluster.
- getHbck(ServerName) - Method in class org.apache.hadoop.hbase.client.AsyncConnectionImpl
- getHbck(ServerName) - Method in interface org.apache.hadoop.hbase.client.Connection
-
Retrieve an Hbck implementation to fix an HBase cluster.
- getHbck(ServerName) - Method in class org.apache.hadoop.hbase.client.SharedAsyncConnection
- getHbck(ServerName) - Method in class org.apache.hadoop.hbase.client.SharedConnection
- getHbckChore() - Method in class org.apache.hadoop.hbase.master.HMaster
- getHbckChore() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Returns Master's instance of
HbckChore
- getHDFSBlockDistribution() - Method in class org.apache.hadoop.hbase.regionserver.HStoreFile
- getHDFSBlockDistribution() - Method in class org.apache.hadoop.hbase.regionserver.InputStreamBlockDistribution
-
Get the HDFSBlocksDistribution derived from the StoreFile input stream, re-computing if cache is expired.
- getHDFSBlockDistribution() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
Returns the HDFS block distribution
- getHDFSBlocksDistribution() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
- getHdfsEntry() - Method in class org.apache.hadoop.hbase.util.HbckRegionInfo
- getHdfsHRI() - Method in class org.apache.hadoop.hbase.util.HbckRegionInfo
- getHdfsRegionDir() - Method in class org.apache.hadoop.hbase.util.HbckRegionInfo
- getHeader() - Method in enum class org.apache.hadoop.hbase.hbtop.field.Field
- getHeader() - Method in enum class org.apache.hadoop.hbase.hbtop.mode.Mode
- getHeader() - Method in interface org.apache.hadoop.hbase.ipc.RpcCall
-
Returns The request header of this call.
- getHeader() - Method in class org.apache.hadoop.hbase.ipc.ServerCall
- getHeader(String) - Method in class org.apache.hadoop.hbase.rest.client.Response
- getHeaders() - Method in class org.apache.hadoop.hbase.rest.client.Response
-
Returns the HTTP response headers
- getHeap() - Method in class org.apache.hadoop.hbase.regionserver.KeyValueHeap
-
Returns the current Heap
- getHeapAllocationBytes() - Method in class org.apache.hadoop.hbase.io.ByteBuffAllocator
- getHeapAllocationBytes(ByteBuffAllocator...) - Static method in class org.apache.hadoop.hbase.io.ByteBuffAllocator
- getHeapAllocationRatio(ByteBuffAllocator...) - Static method in class org.apache.hadoop.hbase.io.ByteBuffAllocator
- getHeapMemoryManager() - Method in class org.apache.hadoop.hbase.MockRegionServerServices
- getHeapMemoryManager() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
- getHeapMemoryManager() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceFactory
-
Get a MetricsHeapMemoryManagerSource
- getHeapMemoryManager() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceFactoryImpl
- getHeapMemoryManager() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
Returns heap memory manager instance
- getHeapOccupancy() - Method in class org.apache.hadoop.hbase.client.RegionLoadStats
- getHeapOccupancyPercent() - Method in class org.apache.hadoop.hbase.client.backoff.ServerStatistics.RegionStatistics
- getHeapOccupancyPercent() - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager
-
Returns heap occupancy percentage, 0 <= n <= 1.
- getHeapSize() - Method in class org.apache.hadoop.hbase.regionserver.CompositeImmutableSegment
-
Returns The heap size of this segment.
- getHeapSize() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreSize
- getHeapSize() - Method in interface org.apache.hadoop.hbase.regionserver.MemStoreSizing
- getHeapSize() - Method in class org.apache.hadoop.hbase.regionserver.Segment
- getHeapUsageThreshold() - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
- getHedgedReadOps() - Method in class org.apache.hadoop.hbase.client.MetricsConnection
-
hedgedReadOps metric
- getHedgedReadOps() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Returns Count of hedged read operations
- getHedgedReadOpsInCurThread() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Returns Count of times a hedged read executes in current thread
- getHedgedReadWin() - Method in class org.apache.hadoop.hbase.client.MetricsConnection
-
hedgedReadWin metric
- getHedgedReadWins() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Returns Count of times a hedged read beat out the primary read.
- getHFileBlock() - Method in class org.apache.hadoop.hbase.io.hfile.BlockWithScanInfo
- getHFileCleaner() - Method in class org.apache.hadoop.hbase.master.HMaster
- getHFileCleaners() - Method in class org.apache.hadoop.hbase.master.HMaster
- getHFileContext() - Method in interface org.apache.hadoop.hbase.io.encoding.HFileBlockDecodingContext
-
Returns HFile meta information
- getHFileContext() - Method in class org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultDecodingContext
- getHFileContext() - Method in class org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultEncodingContext
- getHFileContext() - Method in interface org.apache.hadoop.hbase.io.encoding.HFileBlockEncodingContext
-
Returns HFile context information
- getHFileContext() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
- getHFileContext() - Method in class org.apache.hadoop.hbase.io.hfile.HFileInfo
- getHFilecorruptionChecker() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- getHFileFromBackReference(Configuration, Path) - Static method in class org.apache.hadoop.hbase.io.HFileLink
-
Get the full path of the HFile referenced by the back reference
- getHFileFromBackReference(Path, Path) - Static method in class org.apache.hadoop.hbase.io.HFileLink
-
Get the full path of the HFile referenced by the back reference
- getHFileInfo() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
- getHFileInfo() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
- getHFileInfo() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
- getHFileMinorVersion() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileReader
- getHfileName() - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheKey
-
Returns The hfileName portion of this cache key
- getHFileName() - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
- getHFileNames(Configuration, FileSystem, Path) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotReferenceUtil
-
Returns the store file names in the snapshot.
- getHFileReader() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileReader
- getHFilesChecked() - Method in class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
-
Returns number of hfiles checked in the last HfileCorruptionChecker run
- getHFilesSize() - Method in class org.apache.hadoop.hbase.regionserver.HStore
- getHFilesSize() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Returns The size of only the store files which are HFiles, in bytes.
- getHFileVersion() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileReader
- getHfs() - Method in class org.apache.hadoop.hbase.io.FSDataInputStreamWrapper
- getHistogram() - Method in interface org.apache.hadoop.hbase.metrics.Timer
- getHistogramReport(Histogram) - Static method in class org.apache.hadoop.hbase.util.YammerHistogramUtils
-
Returns a summary of
hist
. - getHistory(int) - Method in interface org.apache.hadoop.hbase.backup.BackupAdmin
-
Show backup history command
- getHistory(int, BackupInfo.Filter...) - Method in interface org.apache.hadoop.hbase.backup.BackupAdmin
-
Show backup history command with filters
- getHitCachingCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
- getHitCachingCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
- getHitCachingRatio() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
- getHitCachingRatioPastNPeriods() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
- getHitCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
- getHitCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
- getHitRatio() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
- getHitRatio() - Method in class org.apache.hadoop.hbase.mob.MobFileCache
-
Gets the hit ratio to the mob file cache.
- getHitRatioPastNPeriods() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
- getHLogTargetDir() - Method in class org.apache.hadoop.hbase.backup.BackupInfo
- getHost() - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution.HostAndWeight
-
Returns the host name
- getHostAndWeights() - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution
-
Returns the hosts and their weights
- getHostname() - Method in exception org.apache.hadoop.hbase.exceptions.RegionMovedException
- getHostname() - Method in class org.apache.hadoop.hbase.HRegionLocation
- getHostname() - Method in exception org.apache.hadoop.hbase.ipc.RemoteWithExtrasException
-
Returns null if not set
- getHostname() - Method in class org.apache.hadoop.hbase.net.Address
-
Deprecated.Use
Address.getHostName()
instead - getHostname() - Method in class org.apache.hadoop.hbase.ServerName
- getHostname(Configuration, String) - Method in class org.apache.hadoop.hbase.HBaseRpcServicesBase
- getHostname(Configuration, String) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- getHostname(Configuration, String) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
- getHostname(Configuration, DNS.ServerType) - Static method in class org.apache.hadoop.hbase.util.DNS
-
Get the configured hostname for a given ServerType.
- getHostName() - Static method in class org.apache.hadoop.hbase.chaos.ChaosUtils
- getHostName() - Method in class org.apache.hadoop.hbase.HbckServerName
- getHostName() - Method in class org.apache.hadoop.hbase.net.Address
- getHostName() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsUserSource.ClientMetrics
- getHostName() - Method in interface org.apache.hadoop.hbase.UserMetrics.ClientMetrics
- getHostName() - Method in class org.apache.hadoop.hbase.UserMetricsBuilder.ClientMetricsImpl
- getHostnameLowerCase() - Method in class org.apache.hadoop.hbase.ServerName
- getHostnamePort() - Method in class org.apache.hadoop.hbase.HRegionLocation
-
Returns String made of hostname and port formatted as per
Addressing.createHostAndPortStr(String, int)
- getHostnamePort(int) - Method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
- getHostPort() - Method in class org.apache.hadoop.hbase.HbckServerName
- getHRegion() - Method in class org.apache.hadoop.hbase.regionserver.HStore
- getHris() - Method in class org.apache.hadoop.hbase.regionserver.RegionServerServices.RegionStateTransitionContext
- getHtd() - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.InputSplit
- getHttpClient() - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Returns the wrapped HttpClient
- getHttpServer() - Method in class org.apache.hadoop.hbase.thrift.ThriftServer
-
the Jetty server, not null means the HTTP server is started, for test only
- getId() - Method in class org.apache.hadoop.hbase.client.ImmutableScan
- getId() - Method in class org.apache.hadoop.hbase.client.OperationWithAttributes
-
This method allows you to retrieve the identifier for the operation if one was set.
- getId() - Method in enum class org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
-
Returns The id of a data block encoder.
- getId() - Method in enum class org.apache.hadoop.hbase.io.encoding.IndexBlockEncoding
-
Returns The id of a data block encoder.
- getId() - Method in enum class org.apache.hadoop.hbase.io.hfile.BlockType
-
Use this instead of
Enum.ordinal()
. - getId() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreSnapshot
-
Returns snapshot's identifier.
- getId() - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeer
-
Get the identifier of this peer
- getId() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerImpl
-
Get the identifier of this peer
- getId() - Method in class org.apache.hadoop.hbase.replication.ReplicationQueueData
- getId() - Method in class org.apache.hadoop.hbase.zookeeper.ZKClusterId
- getID() - Method in class org.apache.hadoop.hbase.rest.ScannerResultGenerator
- getIdentifier() - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
- getIdentifier(String, SecretManager<T>) - Static method in class org.apache.hadoop.hbase.security.HBaseSaslRpcServer
- getIfCached(Path) - Static method in class org.apache.hadoop.hbase.util.CoprocessorClassLoader
- getIfPresentOrNew() - Method in class org.apache.hadoop.hbase.regionserver.wal.SyncFutureCache
- getImmutableSegments() - Method in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
- getImplementationClassName() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
-
Deprecated.Since 3.0.0, will be removed in 4.0.0. You can not set it any more as the implementation has to use too many internal stuffs in HBase.
- getIncrBackupFileList() - Method in class org.apache.hadoop.hbase.backup.BackupInfo
- getIncrementTracker() - Method in class org.apache.hadoop.hbase.client.MetricsConnection
-
incrementTracker metric
- getIncrTimestampMap() - Method in class org.apache.hadoop.hbase.backup.BackupInfo
-
Get new region server log timestamps after distributed log roll
- getIndexBlockCount() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
- getIndexBlockEncoding() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Return the index block encoding algorithm used in block cache and optionally on disk
- getIndexBlockEncoding() - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
- getIndexBlockEncoding() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileIndexBlockEncoder
-
Returns the index block encoding
- getIndexBlockEncoding() - Method in class org.apache.hadoop.hbase.io.hfile.HFileIndexBlockEncoderImpl
- getIndexBlockEncoding() - Method in class org.apache.hadoop.hbase.io.hfile.NoOpIndexBlockEncoder
- getIndexType() - Method in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
- getInflightWALCloseCount() - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
Returns number of WALs currently in the process of closing.
- getInfo(String) - Static method in class org.apache.hadoop.hbase.security.SecurityInfo
-
Returns the security configuration associated with the given service name.
- getInfoPort() - Method in class org.apache.hadoop.hbase.rest.RESTServer
- getInfoPort(ServerName) - Method in class org.apache.hadoop.hbase.master.ServerManager
- getInfoServer() - Method in class org.apache.hadoop.hbase.HBaseServerBase
- getInfoServerPort() - Method in interface org.apache.hadoop.hbase.ServerMetrics
- getInitialClusterMetrics() - Method in class org.apache.hadoop.hbase.HBaseCluster
-
Deprecated.Returns a ClusterStatus for this HBase cluster as observed at the starting of the HBaseCluster
- getInitialCount() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreConfig
- getInitialDelay() - Method in class org.apache.hadoop.hbase.ScheduledChore
-
Returns initial delay before executing chore in getTimeUnit() units
- getInitialFilters() - Method in class org.apache.hadoop.hbase.hbtop.mode.DrillDownInfo
- getInitialFunctionCosts() - Method in class org.apache.hadoop.hbase.client.BalancerDecision
- getInitializedEvent() - Method in class org.apache.hadoop.hbase.master.HMaster
- getInitializedEvent() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Returns Tripped when Master has finished initialization.
- getInitialResponse() - Method in class org.apache.hadoop.hbase.security.AbstractHBaseSaslRpcClient
-
Computes the initial response a client sends to a server to begin the SASL challenge/response handshake.
- getInitialState() - Method in class org.apache.hadoop.hbase.regionserver.storefiletracker.ModifyStoreFileTrackerProcedure
- getInitiatingMasterActiveTime() - Method in class org.apache.hadoop.hbase.regionserver.RegionServerServices.PostOpenDeployContext
- getInitiatingMasterActiveTime() - Method in class org.apache.hadoop.hbase.regionserver.RegionServerServices.RegionStateTransitionContext
- getInitTotalCost() - Method in class org.apache.hadoop.hbase.client.BalancerDecision
- getInlineBlockType() - Method in class org.apache.hadoop.hbase.io.hfile.CompoundBloomFilterWriter
- getInlineBlockType() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexWriter
- getInlineBlockType() - Method in interface org.apache.hadoop.hbase.io.hfile.InlineBlockWriter
-
The type of blocks this block writer produces.
- getInMemoryCompaction() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Returns in-memory compaction policy if set for the cf.
- getInnerStoreCellComparator(byte[]) - Static method in class org.apache.hadoop.hbase.InnerStoreCellComparator
-
Utility method that makes a guess at comparator to use based off passed tableName.
- getInnerStoreCellComparator(TableName) - Static method in class org.apache.hadoop.hbase.InnerStoreCellComparator
-
Utility method that makes a guess at comparator to use based off passed tableName.
- getInputStream() - Method in class org.apache.hadoop.hbase.codec.BaseDecoder
- getInputStream() - Method in class org.apache.hadoop.hbase.security.HBaseSaslRpcClient
-
Get a SASL wrapped InputStream.
- getInputStreamWrapper() - Method in class org.apache.hadoop.hbase.io.hfile.ReaderContext
- getInstance() - Static method in interface org.apache.hadoop.hbase.CellComparator
-
A comparator for ordering cells in user-space tables.
- getInstance() - Method in class org.apache.hadoop.hbase.coprocessor.BaseEnvironment
- getInstance() - Method in interface org.apache.hadoop.hbase.CoprocessorEnvironment
-
Returns the loaded coprocessor instance
- getInstance() - Static method in class org.apache.hadoop.hbase.io.crypto.CryptoCipherProvider
- getInstance() - Static method in class org.apache.hadoop.hbase.io.crypto.DefaultCipherProvider
- getInstance() - Static method in class org.apache.hadoop.hbase.io.MetricsIO
-
Get a static instance for the MetricsIO so that accessors access the same instance.
- getInstance() - Static method in class org.apache.hadoop.hbase.quotas.FileArchiverNotifierFactoryImpl
- getInstance() - Static method in class org.apache.hadoop.hbase.quotas.NoOpRegionSizeStore
- getInstance() - Static method in class org.apache.hadoop.hbase.quotas.policies.MissingSnapshotViolationPolicyEnforcement
- getInstance() - Static method in class org.apache.hadoop.hbase.quotas.RegionSizeStoreFactory
- getInstance() - Static method in class org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshotNotifierFactory
- getInstance() - Static method in class org.apache.hadoop.hbase.quotas.SpaceViolationPolicyEnforcementFactory
-
Returns an instance of this factory.
- getInstance() - Static method in class org.apache.hadoop.hbase.regionserver.ChunkCreator
- getInstance() - Static method in class org.apache.hadoop.hbase.regionserver.NoLimitScannerContext
-
Returns the static, immutable instance of
NoLimitScannerContext
to be used whenever limits should not be enforced - getInstance() - Static method in class org.apache.hadoop.hbase.rest.RESTServlet
-
Returns the RESTServlet singleton instance
- getInstance() - Static method in class org.apache.hadoop.hbase.util.JenkinsHash
- getInstance() - Static method in class org.apache.hadoop.hbase.util.MurmurHash
- getInstance() - Static method in class org.apache.hadoop.hbase.util.MurmurHash3
- getInstance(int) - Static method in class org.apache.hadoop.hbase.util.Hash
-
Get a singleton instance of hash function of a given type.
- getInstance(Class<T>) - Static method in class org.apache.hadoop.hbase.CompatibilityFactory
- getInstance(Class<T>) - Static method in class org.apache.hadoop.hbase.CompatibilitySingletonFactory
-
Get the singleton instance of Any classes defined by compatibiliy jar's
- getInstance(Configuration) - Static method in class org.apache.hadoop.hbase.namequeues.NamedQueueRecorder
- getInstance(Configuration) - Static method in class org.apache.hadoop.hbase.util.Hash
-
Get a singleton instance of hash function of a type defined in the configuration.
- getInstance(Configuration) - Static method in class org.apache.hadoop.hbase.wal.WALFactory
- getInstance(Configuration, UserProvider) - Static method in class org.apache.hadoop.hbase.rest.RESTServlet
- getInstances(String, Class<U>) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
- getInt() - Method in class org.apache.hadoop.hbase.nio.ByteBuff
-
Returns the int value at the current position.
- getInt() - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
Returns the int value at the current position.
- getInt() - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
- getInt() - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
- getInt() - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
Retrieve the next int value from this range.
- getInt(int) - Method in class org.apache.hadoop.hbase.nio.ByteBuff
-
Fetches the int at the given index.
- getInt(int) - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
Fetches the int at the given index.
- getInt(int) - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
- getInt(int) - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
- getInt(int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Retrieve the int value at
index
- getInt(String, int) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
- getIntAfterPosition(int) - Method in class org.apache.hadoop.hbase.nio.ByteBuff
-
Fetches the int value at the given offset from current position.
- getIntAfterPosition(int) - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
- getIntAfterPosition(int) - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
- getIntermediateIndexHitCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
- getIntermediateIndexHitCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
- getIntermediateIndexHitCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
- getIntermediateIndexMissCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
- getIntermediateIndexMissCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
- getIntermediateIndexMissCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
- getInternalBalancer() - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupBasedLoadBalancer
- getInts(String) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
- getIp4Address() - Static method in class org.apache.hadoop.hbase.util.Addressing
- getIp6Address() - Static method in class org.apache.hadoop.hbase.util.Addressing
- getIpAddress() - Static method in class org.apache.hadoop.hbase.util.Addressing
- getIsActiveMaster() - Method in interface org.apache.hadoop.hbase.master.MetricsMasterWrapper
-
Whether this master is the active master
- getIsActiveMaster() - Method in class org.apache.hadoop.hbase.master.MetricsMasterWrapperImpl
- getIsolationLevel() - Method in class org.apache.hadoop.hbase.client.ImmutableScan
- getIsolationLevel() - Method in class org.apache.hadoop.hbase.client.Query
-
Returns The isolation level of this query.
- getIterator() - Method in class org.apache.hadoop.hbase.rest.TableScanResource.CellSetModelStream
- getIterator(int) - Method in class org.apache.hadoop.hbase.io.encoding.EncodedDataBlock
-
Provides access to compressed value.
- getIterator(ExtendedCell) - Method in class org.apache.hadoop.hbase.regionserver.SegmentScanner
- getIv() - Method in class org.apache.hadoop.hbase.io.crypto.aes.AESEncryptor
- getIv() - Method in class org.apache.hadoop.hbase.io.crypto.aes.CommonsCryptoAESEncryptor
- getIv() - Method in interface org.apache.hadoop.hbase.io.crypto.Encryptor
-
Get the initialization vector
- getIvLength() - Method in class org.apache.hadoop.hbase.io.crypto.aes.AES
- getIvLength() - Method in class org.apache.hadoop.hbase.io.crypto.aes.AESDecryptor
- getIvLength() - Method in class org.apache.hadoop.hbase.io.crypto.aes.AESEncryptor
- getIvLength() - Method in class org.apache.hadoop.hbase.io.crypto.aes.CommonsCryptoAES
- getIvLength() - Method in class org.apache.hadoop.hbase.io.crypto.aes.CommonsCryptoAESDecryptor
- getIvLength() - Method in class org.apache.hadoop.hbase.io.crypto.aes.CommonsCryptoAESEncryptor
- getIvLength() - Method in class org.apache.hadoop.hbase.io.crypto.Cipher
-
Return the expected initialization vector length, in bytes, or 0 if not applicable
- getIvLength() - Method in interface org.apache.hadoop.hbase.io.crypto.Decryptor
-
Get the expected length for the initialization vector
- getIvLength() - Method in interface org.apache.hadoop.hbase.io.crypto.Encryptor
-
Get the expected length for the initialization vector
- getJar(Class) - Static method in class org.apache.hadoop.hbase.mapreduce.JarFinder
-
Returns the full path to the Jar containing the class.
- getJarPath() - Method in interface org.apache.hadoop.hbase.client.CoprocessorDescriptor
-
Returns Path of the jar file.
- org.apache.hadoop.hbase.util.GetJavaProperty - Class in org.apache.hadoop.hbase.util
-
A generic way for querying Java properties.
- getJitter() - Method in class org.apache.hadoop.hbase.util.RetryCounter.RetryConfig
- getJVMSpecVersion() - Static method in class org.apache.hadoop.hbase.util.JVM
- getKeepDeletedCells() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Returns return the KeepDeletedCells
- getKeepDeletedCells() - Method in class org.apache.hadoop.hbase.regionserver.CustomizedScanInfoBuilder
- getKeepDeletedCells() - Method in class org.apache.hadoop.hbase.regionserver.ScanInfo
- getKeepDeletedCells() - Method in interface org.apache.hadoop.hbase.regionserver.ScanOptions
- getKey() - Method in class org.apache.hadoop.hbase.io.crypto.Context
- getKey() - Method in interface org.apache.hadoop.hbase.io.encoding.DataBlockEncoder.EncodedSeeker
-
From the current position creates a cell using the key part of the current buffer
- getKey() - Method in class org.apache.hadoop.hbase.io.encoding.RowIndexSeekerV1
- getKey() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.EncodedScanner
- getKey() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
- getKey() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
-
Gets the current key in the form of a cell.
- getKey() - Method in class org.apache.hadoop.hbase.KeyValue
-
Do not use unless you have to.
- getKey() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
- getKey() - Method in class org.apache.hadoop.hbase.wal.WAL.Entry
-
Gets the key
- getKey(String) - Method in interface org.apache.hadoop.hbase.io.crypto.KeyProvider
-
Retrieve the key for a given key aliase
- getKey(String) - Method in class org.apache.hadoop.hbase.io.crypto.KeyStoreKeyProvider
- getKey(String) - Method in class org.apache.hadoop.hbase.io.crypto.MockAesKeyProvider
- getKeyBytes() - Method in class org.apache.hadoop.hbase.io.crypto.Context
- getKeyBytesHash() - Method in class org.apache.hadoop.hbase.io.crypto.Context
- getKeyCount() - Method in class org.apache.hadoop.hbase.io.hfile.CompoundBloomFilterBase
- getKeyCount() - Method in interface org.apache.hadoop.hbase.util.BloomFilterBase
-
Returns The number of keys added to the bloom
- getKeyCount() - Method in class org.apache.hadoop.hbase.util.BloomFilterChunk
- getKeyDataStructureSize(int, int, int) - Static method in class org.apache.hadoop.hbase.KeyValue
-
Computes the number of bytes that a
KeyValue
instance with the provided characteristics would take up in its underlying data structure for the key. - getKeyFormat() - Method in class org.apache.hadoop.hbase.io.crypto.Context
- getKeyForNextColumn(ExtendedCell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher
- getKeyLength() - Method in class org.apache.hadoop.hbase.io.crypto.aes.AES
- getKeyLength() - Method in class org.apache.hadoop.hbase.io.crypto.aes.CommonsCryptoAES
- getKeyLength() - Method in class org.apache.hadoop.hbase.io.crypto.Cipher
-
Return the key length required by this cipher, in bytes
- getKeyLength() - Method in class org.apache.hadoop.hbase.KeyValue
-
Returns Length of key portion.
- getKeyLength() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
- getKeyLength() - Method in class org.apache.hadoop.hbase.SizeCachedByteBufferKeyValue
- getKeyLength() - Method in class org.apache.hadoop.hbase.SizeCachedKeyValue
- getKeyLength() - Method in class org.apache.hadoop.hbase.SizeCachedNoTagsByteBufferKeyValue
- getKeyOfBiggestCell() - Method in class org.apache.hadoop.hbase.io.hfile.HFileInfo
- getKeyOffset() - Method in class org.apache.hadoop.hbase.KeyValue
-
Returns Key offset in backing buffer..
- getKeyOffset() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
- getKeyProvider(Configuration) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
- getKeys() - Method in class org.apache.hadoop.hbase.hbtop.screen.help.CommandDescription
- getKeys(String[]) - Method in interface org.apache.hadoop.hbase.io.crypto.KeyProvider
-
Retrieve keys for a given set of key aliases
- getKeys(String[]) - Method in class org.apache.hadoop.hbase.io.crypto.KeyStoreKeyProvider
- getKeys(String[]) - Method in class org.apache.hadoop.hbase.io.crypto.MockAesKeyProvider
- getKeyString() - Method in class org.apache.hadoop.hbase.KeyValue
- getKeyValueDataStructureSize(int, int, int) - Static method in class org.apache.hadoop.hbase.KeyValue
-
Computes the number of bytes that a
KeyValue
instance with the provided characteristics would take up for its underlying data structure. - getKeyValueDataStructureSize(int, int, int, int) - Static method in class org.apache.hadoop.hbase.KeyValue
-
Computes the number of bytes that a
KeyValue
instance with the provided characteristics would take up for its underlying data structure. - getKeyValueDataStructureSize(int, int, int, int, int) - Static method in class org.apache.hadoop.hbase.KeyValue
-
Computes the number of bytes that a
KeyValue
instance with the provided characteristics would take up for its underlying data structure. - getKeyValues(Configuration, String) - Static method in class org.apache.hadoop.hbase.util.ConfigurationUtil
-
Retrieve a list of key value pairs from configuration, stored under the provided key
- getKeyValues(Configuration, String, char) - Static method in class org.apache.hadoop.hbase.util.ConfigurationUtil
-
Retrieve a list of key value pairs from configuration, stored under the provided key
- getL1CacheCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Number of blocks in L1 cache
- getL1CacheEvictedCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Number of blocks evicted from L1 cache
- getL1CacheFreeSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Free cache size (bytes) of L1 cache
- getL1CacheHitCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Hit count of L1 cache.
- getL1CacheHitRatio() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Hit ratio of L1 cache.
- getL1CacheMissCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Miss count of L1 cache.
- getL1CacheMissRatio() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Miss ratio of L1 cache.
- getL1CacheSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Cache size (bytes) of L1 cache
- getL2CacheCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Number of blocks in L2 cache
- getL2CacheEvictedCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Number of blocks evicted from L2 cache
- getL2CacheFreeSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Free cache size (bytes) of L2 cache
- getL2CacheHitCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Hit count of L2 cache.
- getL2CacheHitRatio() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Hit ratio of L2 cache.
- getL2CacheMissCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Miss count of L2 cache.
- getL2CacheMissRatio() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Miss ratio of L2 cache.
- getL2CacheSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Cache size (bytes) of L2 cache
- getLabels() - Method in class org.apache.hadoop.hbase.rest.RowSpec
- getLargeCompactionQueueSize() - Method in class org.apache.hadoop.hbase.regionserver.CompactSplit
- getLargeCompactionQueueSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
- getLargeCompactionThreadNum() - Method in class org.apache.hadoop.hbase.regionserver.CompactSplit
- getLast(TNode) - Static method in class org.apache.hadoop.hbase.util.AvlUtil.AvlTree
-
Return the last node of the tree.
- getLastAttemptAt() - Method in exception org.apache.hadoop.hbase.exceptions.PreemptiveFastFailException
-
Deprecated.Returns time of the latest attempt
- getLastCell() - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterImpl
- getLastCell() - Method in class org.apache.hadoop.hbase.util.BloomContext
- getLastCompactSize() - Method in class org.apache.hadoop.hbase.regionserver.HStore
- getLastCompactSize() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Returns aggregate size of all HStores used in the last compaction
- getLastDataBlockOffset() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
- getLastFlushedSequenceId(byte[]) - Method in class org.apache.hadoop.hbase.master.ServerManager
- getLastFlushedSequenceId(RpcController, RegionServerStatusProtos.GetLastFlushedSequenceIdRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- getLastFlushedSequenceId(RpcController, RegionServerStatusProtos.GetLastFlushedSequenceIdRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServicesVersionWrapper
- getLastGcDuration(ObjectName) - Static method in class org.apache.hadoop.hbase.util.JSONMetricUtil
- getLastIndexExclusive() - Method in class org.apache.hadoop.hbase.regionserver.MiniBatchOperationInProgress
- getLastKey() - Method in class org.apache.hadoop.hbase.io.HalfStoreFileReader
- getLastKey() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
- getLastKey() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
- getLastKey() - Method in class org.apache.hadoop.hbase.regionserver.HStoreFile
- getLastKey() - Method in interface org.apache.hadoop.hbase.regionserver.StoreFile
-
Get the last key in this store file.
- getLastKey() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileReader
- getLastKeyCell() - Method in class org.apache.hadoop.hbase.io.hfile.HFileInfo
- getLastMajorCompactionAge() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
-
Returns Age of the last major compaction
- getLastMajorCompactionAge() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
- getLastMajorCompactionTimestamp() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
Returns the timestamp of the oldest hfile for any store of this region.
- getLastMajorCompactionTimestamp(byte[]) - Method in interface org.apache.hadoop.hbase.ClusterMetrics
- getLastMajorCompactionTimestamp(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get the timestamp of the last major compaction for the passed table The timestamp of the oldest HFile resulting from a major compaction of that table, or 0 if no such HFile could be found.
- getLastMajorCompactionTimestamp(TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Get the timestamp of the last major compaction for the passed table.
- getLastMajorCompactionTimestamp(TableName) - Method in interface org.apache.hadoop.hbase.ClusterMetrics
- getLastMajorCompactionTimestamp(TableName) - Method in class org.apache.hadoop.hbase.master.HMaster
- getLastMajorCompactionTimestamp(TableName) - Method in interface org.apache.hadoop.hbase.master.MasterServices
- getLastMajorCompactionTimestamp(RpcController, MasterProtos.MajorCompactionTimestampRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- getLastMajorCompactionTimestampForRegion(byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get the timestamp of the last major compaction for the passed region.
- getLastMajorCompactionTimestampForRegion(byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Get the timestamp of the last major compaction for the passed region.
- getLastMajorCompactionTimestampForRegion(byte[]) - Method in class org.apache.hadoop.hbase.master.HMaster
- getLastMajorCompactionTimestampForRegion(byte[]) - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Returns the timestamp of the last successful major compaction for the passed region or 0 if no HFile resulting from a major compaction exists
- getLastMajorCompactionTimestampForRegion(RpcController, MasterProtos.MajorCompactionTimestampForRegionRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- getLastPushedSeqId() - Method in class org.apache.hadoop.hbase.replication.ZKReplicationQueueStorageForMigration.ZkLastPushedSeqId
- getLastQuery() - Method in class org.apache.hadoop.hbase.quotas.QuotaState
- getLastReportTimestamp() - Method in interface org.apache.hadoop.hbase.ServerMetrics
-
Returns the last timestamp (server side) of generating this metrics
- getLastRowKey() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
- getLastRowKey() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
-
TODO left from
HFile
version 1: move this to StoreFile after Ryan's patch goes in to eliminateKeyValue
here. - getLastRowKey() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileReader
- getLastSequenceId(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
- getLastSequenceId(byte[]) - Method in interface org.apache.hadoop.hbase.regionserver.LastSequenceId
- getLastSequenceId(String, String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueueStorage
-
Read the max sequence id of the specific region for a given peer.
- getLastSequenceId(String, String) - Method in class org.apache.hadoop.hbase.replication.TableReplicationQueueStorage
- getLastUpdate() - Method in class org.apache.hadoop.hbase.quotas.QuotaState
- getLatestVersionOnly() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
Get whether only the latest version of the column value should be compared.
- getLeafIndexHitCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
- getLeafIndexHitCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
- getLeafIndexHitCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
- getLeafIndexMissCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
- getLeafIndexMissCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
- getLeafIndexMissCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
- getLeaseManager() - Method in class org.apache.hadoop.hbase.MockRegionServerServices
- getLeaseManager() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
- getLeaseManager() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
Returns The RegionServer's "Leases" service
- getLength() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.Header
- getLength() - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
-
Returns the number of valid bytes in the buffer
- getLength() - Method in class org.apache.hadoop.hbase.KeyValue
-
Returns Length of bytes this KeyValue occupies in
KeyValue.getBuffer()
. - getLength() - Method in class org.apache.hadoop.hbase.mapred.TableSnapshotInputFormat.TableSnapshotRegionSplit
- getLength() - Method in class org.apache.hadoop.hbase.mapred.TableSplit
- getLength() - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormat.TableSnapshotRegionSplit
- getLength() - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.InputSplit
- getLength() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
-
Returns the length of the split.
- getLength() - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractProtobufLogWriter
- getLength() - Method in class org.apache.hadoop.hbase.regionserver.wal.CombinedWriterBase
- getLength() - Method in class org.apache.hadoop.hbase.types.FixedLengthWrapper
-
Retrieve the maximum length (in bytes) of encoded values.
- getLength() - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
- getLength() - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
The length of the range.
- getLength() - Method in class org.apache.hadoop.hbase.util.Bytes
-
Returns the number of valid bytes in the buffer
- getLength() - Method in interface org.apache.hadoop.hbase.wal.WALProvider.WriterBase
- getLenOfBiggestCell() - Method in class org.apache.hadoop.hbase.io.hfile.HFileInfo
- getLevel0Files() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
- getLevel0MinFiles() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreConfig
- getLimit() - Method in class org.apache.hadoop.hbase.client.ImmutableScan
- getLimit() - Method in class org.apache.hadoop.hbase.client.LogQueryFilter
-
Deprecated.
- getLimit() - Method in class org.apache.hadoop.hbase.client.Scan
-
Returns the limit of rows for this scan
- getLimit() - Method in class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
- getLimit() - Method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
- getLimit() - Method in class org.apache.hadoop.hbase.quotas.RateLimiter
- getLimit() - Method in class org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot
-
Returns the limit, in bytes, of the target (e.g.
- getLimit() - Method in interface org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshotView
-
Returns the limit, in bytes, of the target (e.g.
- getLimit() - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
- getLimit() - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
Return the current limit
- getListener() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
- getListenerAddress() - Method in class org.apache.hadoop.hbase.ipc.NettyRpcServer
- getListenerAddress() - Method in class org.apache.hadoop.hbase.ipc.RpcScheduler.Context
- getListenerAddress() - Method in interface org.apache.hadoop.hbase.ipc.RpcServerInterface
- getListenerAddress() - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcServer
-
Deprecated.Return the socket (ip+port) on which the RPC server is listening to.
- getListeners() - Method in class org.apache.hadoop.hbase.zookeeper.ZKWatcher
-
Get a copy of current registered listeners
- getListOfServers() - Method in class org.apache.hadoop.hbase.HbckInconsistentRegions
- getLiveMasters() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
- getLiveMasterThreads() - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.Returns List of live master threads (skips the aborted and the killed)
- getLiveRegionServers() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
- getLiveRegionServers() - Method in class org.apache.hadoop.hbase.master.HMaster
- getLiveRegionServers(MasterAddressTracker, int) - Method in interface org.apache.hadoop.hbase.client.AsyncClusterConnection
-
Get live region servers from masters.
- getLiveRegionServers(RpcController, RegionServerStatusProtos.GetLiveRegionServersRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- getLiveRegionServers(RpcController, RegionServerStatusProtos.GetLiveRegionServersRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServicesVersionWrapper
- getLiveRegionServerThreads() - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.Returns List of live region server threads (skips the aborted and the killed)
- getLiveServerMetrics() - Method in interface org.apache.hadoop.hbase.ClusterMetrics
-
Returns the names of region servers on the live list
- getLiveServers() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.Summary
- getLiveServersFromWALDir() - Method in class org.apache.hadoop.hbase.master.MasterWalManager
-
Get Servernames that COULD BE 'alive'; excludes those that have a '-splitting' suffix as these are already being split -- they cannot be 'alive'.
- getLoad(ServerName) - Method in class org.apache.hadoop.hbase.master.ServerManager
-
Returns ServerMetrics if serverName is known else null
- getLoadBalancer() - Method in class org.apache.hadoop.hbase.master.HMaster
- getLoadBalancer() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Returns load balancer
- getLoadBalancerClassName() - Method in class org.apache.hadoop.hbase.master.HMaster
-
Fetch the configured
LoadBalancer
class name. - getLoadColumnFamiliesOnDemandValue() - Method in class org.apache.hadoop.hbase.client.ImmutableScan
- getLoadColumnFamiliesOnDemandValue() - Method in class org.apache.hadoop.hbase.client.Query
-
Get the raw loadColumnFamiliesOnDemand setting; if it's not set, can be null.
- getLoadedCachedBlocksByFile(Configuration, BlockCache) - Static method in class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil
-
Get a
BlockCacheUtil.CachedBlocksByFile
instance and load it up by iterating content inBlockCache
. - getLoadedCoprocessors() - Static method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
- getLoadedCoprocessors() - Static method in class org.apache.hadoop.hbase.master.HMaster
-
The set of loaded coprocessors is stored in a static set.
- getLoadOnOpenBlocks() - Method in class org.apache.hadoop.hbase.io.hfile.HFileInfo
- getLoadOnOpenDataOffset() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
- getLoadSequence() - Method in class org.apache.hadoop.hbase.coprocessor.BaseEnvironment
- getLoadSequence() - Method in interface org.apache.hadoop.hbase.CoprocessorEnvironment
-
Returns the load sequence number
- getLoadStatistics() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Returns statistics about the current load of the region
- getLocalBytesRead() - Static method in class org.apache.hadoop.hbase.io.FSDataInputStreamWrapper
- getLocalBytesRead() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Returns Number of bytes read from the local HDFS DataNode.
- getLocalConfiguration() - Method in class org.apache.hadoop.hbase.replication.ReplicationEndpoint.Context
- getLocalPath(String, String) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
- getLocalTableDirs(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
- getLocatedBlockLocations(LocatedBlock) - Static method in class org.apache.hadoop.hbase.util.LocatedBlockHelper
- getLocation() - Method in class org.apache.hadoop.hbase.rest.client.Response
-
Returns the value of the Location header
- getLocations() - Method in class org.apache.hadoop.hbase.io.FileLink
-
Returns the locations to look for the linked file.
- getLocations() - Method in class org.apache.hadoop.hbase.mapred.TableSnapshotInputFormat.TableSnapshotRegionSplit
- getLocations() - Method in class org.apache.hadoop.hbase.mapred.TableSplit
- getLocations() - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormat.TableSnapshotRegionSplit
- getLocations() - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.InputSplit
- getLocations() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
-
Returns the region's location as an array.
- getLocations(TableName) - Method in class org.apache.hadoop.hbase.regionserver.HMobStore
- getLocationSeqNum() - Method in exception org.apache.hadoop.hbase.exceptions.RegionMovedException
- getLock() - Method in class org.apache.hadoop.hbase.regionserver.HRegion.RowLockImpl
- getLock(T) - Method in class org.apache.hadoop.hbase.util.IdReadWriteLock
- getLock(T) - Method in class org.apache.hadoop.hbase.util.IdReadWriteLockStrongRef
- getLock(T) - Method in class org.apache.hadoop.hbase.util.IdReadWriteLockWithObjectPool
-
Get the ReentrantReadWriteLock corresponding to the given id
- getLockedRows() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
- getLockEntry(long) - Method in class org.apache.hadoop.hbase.util.IdLock
-
Blocks until the lock corresponding to the given id is acquired.
- getLockManager() - Method in class org.apache.hadoop.hbase.master.HMaster
- getLockManager() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Returns
LockManager
to lock namespaces/tables/regions. - getLocks() - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get locks.
- getLocks() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
List locks.
- getLocks() - Method in class org.apache.hadoop.hbase.master.HMaster
- getLocks() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Get locks
- getLocks(RpcController, MasterProtos.GetLocksRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- getLogCleaner() - Method in class org.apache.hadoop.hbase.master.HMaster
- getLogEntries(Set<ServerName>, String, ServerType, int, Map<String, Object>) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Retrieve recent online records from HMaster / RegionServers.
- getLogEntries(Set<ServerName>, String, ServerType, int, Map<String, Object>) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Retrieve recent online records from HMaster / RegionServers.
- getLogEntries(RpcController, HBaseProtos.LogRequest) - Method in class org.apache.hadoop.hbase.HBaseRpcServicesBase
- getLogEntries(RpcController, HBaseProtos.LogRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- getLogFileSize() - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
Returns the size of log files in use
- getLogFileSize() - Method in class org.apache.hadoop.hbase.wal.AbstractWALProvider
- getLogFileSize() - Method in interface org.apache.hadoop.hbase.wal.WALProvider
-
Get size of the log files this provider is managing
- getLogFileSize(WAL) - Static method in class org.apache.hadoop.hbase.wal.AbstractFSWALProvider
-
returns the size of rolled WAL files.
- getLogFileSize0() - Method in class org.apache.hadoop.hbase.wal.AbstractFSWALProvider
-
iff the given WALFactory is using the DefaultWALProvider for meta and/or non-meta, count the size of files (only rolled).
- getLogFileSize0() - Method in class org.apache.hadoop.hbase.wal.AbstractWALProvider
- getLogFileSize0() - Method in class org.apache.hadoop.hbase.wal.RegionGroupingProvider
- getLogFileSizeIfBeingWritten(Path) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
if the given
path
is being written currently, then return its length. - getLoginContext() - Static method in class org.apache.hadoop.hbase.util.ClientUtils
-
To authenticate the demo client, kinit should be invoked ahead.
- getLogsCount() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
-
Returns the number of available log files
- getLogsSize() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
-
Returns the total log size
- getLong() - Method in class org.apache.hadoop.hbase.nio.ByteBuff
-
Returns the long value at the current position.
- getLong() - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
Returns the long value at the current position.
- getLong() - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
- getLong() - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
- getLong() - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
Retrieve the next long value from this range.
- getLong(int) - Method in class org.apache.hadoop.hbase.nio.ByteBuff
-
Fetches the long at the given index.
- getLong(int) - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
Fetches the long at the given index.
- getLong(int) - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
- getLong(int) - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
- getLong(int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Retrieve the long value at
index
- getLong(String, long) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
- getLongAfterPosition(int) - Method in class org.apache.hadoop.hbase.nio.ByteBuff
-
Fetches the long value at the given offset from current position.
- getLongAfterPosition(int) - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
- getLongAfterPosition(int) - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
- getLongBytes(String, long) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
- getLongValue() - Method in class org.apache.hadoop.hbase.Size
-
get the value
- getLowest(ExtendedCell, ExtendedCell) - Method in class org.apache.hadoop.hbase.regionserver.AbstractMemStore
-
Returns Return lowest of a or b or null if both a and b are null
- getLowestSequenceId(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.wal.SequenceIdAccounting
-
Returns the lowest unflushed sequence id for the region.
- getLowestTimestamp(Collection<HStoreFile>) - Static method in class org.apache.hadoop.hbase.regionserver.StoreUtils
-
Gets lowest timestamp from candidate StoreFiles
- getLruCacheStats() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
- getMajorCompactedCellsCount() - Method in class org.apache.hadoop.hbase.regionserver.HStore
- getMajorCompactedCellsCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the number of cells processed during major compactions.
- getMajorCompactedCellsCount() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Returns The number of cells processed during major compactions
- getMajorCompactedCellsSize() - Method in class org.apache.hadoop.hbase.regionserver.HStore
- getMajorCompactedCellsSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the total amount of data processed during major compactions, in bytes.
- getMajorCompactedCellsSize() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Returns The total amount of data processed during major compactions, in bytes
- getMajorCompactionCompressionType() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Returns Compression type setting for major compactions.
- getMajorCompactionRequest(RegionInfo) - Method in class org.apache.hadoop.hbase.util.compaction.MajorCompactor
- getMajorCompactionRequest(RegionInfo) - Method in class org.apache.hadoop.hbase.util.compaction.MajorCompactorTTL
- getMajorVersion() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
Returns the major version of this HFile format
- getMajorVersion() - Method in class org.apache.hadoop.hbase.io.hfile.HFileInfo
- getMajorVersion() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
- getMajorVersion() - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterImpl
- getMajorVersion(String) - Static method in class org.apache.hadoop.hbase.util.VersionInfo
- getManifest(Configuration, Path, String) - Static method in class org.apache.hadoop.hbase.backup.HBackupFileSystem
- getMap() - Method in class org.apache.hadoop.hbase.client.Result
-
Map of families to all versions of its qualifiers and values.
- getMapperClass(JobContext) - Static method in class org.apache.hadoop.hbase.mapreduce.MultithreadedTableMapper
-
Get the application's mapper class.
- getMaster() - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get the current active master.
- getMaster() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Returns current master server name wrapped by
CompletableFuture
- getMaster() - Method in class org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination.SplitLogManagerDetails
-
Deprecated.Returns the master value
- getMaster() - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.Returns the current active master, if available.
- getMaster() - Method in class org.apache.hadoop.hbase.util.JVMClusterUtil.MasterThread
-
Returns the master
- getMaster(int) - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
Returns the HMaster thread
- getMaster(int) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.Returns the master at the specified index, if available.
- getMasterActiveTime() - Method in class org.apache.hadoop.hbase.master.HMaster
-
Returns timestamp in millis when HMaster became the active master.
- getMasterActiveTime() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Returns timestamp in millis when this master became the active one.
- getMasterAddr(Configuration) - Static method in class org.apache.hadoop.hbase.client.MasterRegistry
-
Deprecated.Builds the default master address end point if it is not specified in the configuration.
- getMasterAddress() - Method in class org.apache.hadoop.hbase.zookeeper.MasterAddressTracker
-
Get the address of the current master if one is available.
- getMasterAddress(boolean) - Method in class org.apache.hadoop.hbase.zookeeper.MasterAddressTracker
-
Get the address of the current master if one is available.
- getMasterAddress(ZKWatcher) - Static method in class org.apache.hadoop.hbase.zookeeper.MasterAddressTracker
-
Get master address.
- getMasterAddressTracker() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Returns Master address tracker instance.
- getMasterClass() - Method in class org.apache.hadoop.hbase.StartMiniClusterOption
-
Deprecated.
- getMasterCoprocessorHost() - Method in class org.apache.hadoop.hbase.master.HMaster
- getMasterCoprocessorHost() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Returns Master's instance of
MasterCoprocessorHost
- getMasterCoprocessorNames() - Method in interface org.apache.hadoop.hbase.client.Admin
-
Helper that delegates to getClusterMetrics().getMasterCoprocessorNames().
- getMasterCoprocessorNames() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Returns a list of master coprocessors wrapped by
CompletableFuture
- getMasterCoprocessorNames() - Method in interface org.apache.hadoop.hbase.ClusterMetrics
- getMasterCoprocessors() - Method in class org.apache.hadoop.hbase.master.HMaster
-
Returns array of coprocessor SimpleNames.
- getMasterFileSystem() - Method in class org.apache.hadoop.hbase.master.HMaster
- getMasterFileSystem() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Returns Master's filesystem
MasterFileSystem
utility class. - getMasterFinishedInitializationTime() - Method in class org.apache.hadoop.hbase.master.HMaster
-
Returns timestamp in millis when HMaster finished becoming the active master
- getMasterIndex(ServerName) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.
- getMasterInfoPort() - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get the info port of the current master if one is available.
- getMasterInfoPort() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Get the info port of the current master if one is available.
- getMasterInfoPort() - Method in interface org.apache.hadoop.hbase.ClusterMetrics
- getMasterInfoPort() - Method in class org.apache.hadoop.hbase.zookeeper.MasterAddressTracker
-
Get the info port of the current master of one is available.
- getMasterInfoPort(ZKWatcher) - Static method in class org.apache.hadoop.hbase.zookeeper.MasterAddressTracker
-
Get master info port.
- getMasterInitializationTime() - Method in interface org.apache.hadoop.hbase.master.MetricsMasterWrapper
-
Get the time in Millis when the master finished initializing/becoming the active master
- getMasterInitializationTime() - Method in class org.apache.hadoop.hbase.master.MetricsMasterWrapperImpl
- getMasterMetrics() - Method in class org.apache.hadoop.hbase.master.HMaster
- getMasterMetrics() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Returns Master's instance of
MetricsMaster
- getMasterName() - Method in interface org.apache.hadoop.hbase.ClusterMetrics
-
Returns detailed information about the current master
ServerName
. - getMasterObserver() - Method in interface org.apache.hadoop.hbase.coprocessor.MasterCoprocessor
- getMasterObserver() - Method in class org.apache.hadoop.hbase.quotas.MasterQuotasObserver
- getMasterProcedureExecutor() - Method in class org.apache.hadoop.hbase.master.HMaster
- getMasterProcedureExecutor() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Returns Master's instance of
ProcedureExecutor
- getMasterProcedureManagerHost() - Method in class org.apache.hadoop.hbase.master.HMaster
-
Returns the underlying MasterProcedureManagerHost
- getMasterProcedureManagerHost() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Returns the underlying MasterProcedureManagerHost
- getMasterQuotaManager() - Method in class org.apache.hadoop.hbase.master.HMaster
- getMasterQuotaManager() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Returns Master's instance of
MasterQuotaManager
- getMasterRegion() - Method in class org.apache.hadoop.hbase.master.HMaster
- getMasterRpcServices() - Method in class org.apache.hadoop.hbase.master.HMaster
- getMasters() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
Returns Read-only list of master threads.
- getMasters(RpcController, RegistryProtos.GetMastersRequest) - Method in class org.apache.hadoop.hbase.HBaseRpcServicesBase
- getMasterServices() - Method in interface org.apache.hadoop.hbase.coprocessor.HasMasterServices
-
Deprecated.Returns An instance of RegionServerServices, an object NOT for Coprocessor consumption.
- getMasterStartTime() - Method in class org.apache.hadoop.hbase.master.HMaster
-
Returns timestamp in millis when HMaster was started.
- getMasterSystemTime() - Method in class org.apache.hadoop.hbase.regionserver.RegionServerServices.PostOpenDeployContext
- getMasterSystemTime() - Method in class org.apache.hadoop.hbase.regionserver.RegionServerServices.RegionStateTransitionContext
- getMasterTasks() - Method in interface org.apache.hadoop.hbase.ClusterMetrics
-
Provide the list of master tasks
- getMasterThread() - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.Returns the current active master thread, if available.
- getMasterThreads() - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.Returns List of master threads.
- getMasterWalManager() - Method in class org.apache.hadoop.hbase.master.HMaster
- getMasterWalManager() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Returns Master's WALs
MasterWalManager
utility class. - getMax() - Method in class org.apache.hadoop.hbase.io.hfile.AgeSnapshot
- getMax() - Method in class org.apache.hadoop.hbase.io.TimeRange
-
Returns the biggest timestamp that should be considered
- getMax() - Method in interface org.apache.hadoop.hbase.metrics.Snapshot
-
Returns the highest value in the snapshot.
- getMax() - Method in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker
-
Returns the maximumTimestamp
- getMax() - Method in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker.NonSyncTimeRangeTracker
- getMax() - Method in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker.SyncTimeRangeTracker
- getMaxAllowedOperationTime() - Method in exception org.apache.hadoop.hbase.errorhandling.TimeoutException
- getMaxAttempts() - Method in class org.apache.hadoop.hbase.util.RetryCounter
- getMaxAttempts() - Method in class org.apache.hadoop.hbase.util.RetryCounter.RetryConfig
- getMaxCachedBlocksByFile(Configuration) - Static method in class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil
- getMaxCacheSize() - Method in class org.apache.hadoop.hbase.CacheEvictionStats
- getMaxChunkSize(Configuration) - Static method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex
- getMaxColumn() - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
-
Returns the max column range for the filter
- getMaxColumnInclusive() - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
-
Returns true if max column is inclusive, false otherwise
- getMaxCompactedStoreFileRefCount() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
Returns the max reference count for any store file among all compacted stores files of this region
- getMaxCompactedStoreFileRefCount() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
Returns get maximum ref count of storeFile among all compacted HStore Files for the HStore
- getMaxCompactedStoreFileRefCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
-
Returns the max number of references active on any store file among all compacted store files that belong to this region
- getMaxCompactedStoreFileRefCount() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
- getMaxCompactionQueueSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
-
Note that this metric is updated periodically and hence might miss some data points.
- getMaxCompactionQueueSize() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
- getMaxFileDescriptorCount() - Method in class org.apache.hadoop.hbase.util.JVM
-
Get the number of the maximum file descriptors the system can use.
- getMaxFileSize() - Method in class org.apache.hadoop.hbase.client.SnapshotDescription
- getMaxFileSize() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
Returns the maximum size upto which a region can grow to after which a region split is triggered.
- getMaxFlushedSeqId() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
- getMaxFlushedSeqId() - Method in interface org.apache.hadoop.hbase.regionserver.Region
- getMaxFlushQueueSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
-
Note that this metric is updated periodically and hence might miss some data points.
- getMaxFlushQueueSize() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
- getMaxFold(Configuration) - Static method in class org.apache.hadoop.hbase.util.BloomFilterFactory
-
Returns the value for Bloom filter max fold in the given configuration
- getMaxHeapSize() - Method in interface org.apache.hadoop.hbase.ServerMetrics
-
Returns the maximum allowable size of the heap
- getMaximumTimestamp() - Method in class org.apache.hadoop.hbase.regionserver.HStoreFile
- getMaximumTimestamp() - Method in interface org.apache.hadoop.hbase.regionserver.StoreFile
-
Get the max timestamp of all the cells in the store file.
- getMaxKeys() - Method in class org.apache.hadoop.hbase.io.hfile.CompoundBloomFilterBase
- getMaxKeys() - Method in interface org.apache.hadoop.hbase.util.BloomFilterBase
-
Returns The max number of keys that can be inserted to maintain the desired error rate
- getMaxKeys() - Method in class org.apache.hadoop.hbase.util.BloomFilterChunk
- getMaxKeys(Configuration) - Static method in class org.apache.hadoop.hbase.util.BloomFilterFactory
-
Returns max key for the Bloom filter from the configuration
- getMaxKeyValueSize() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
- getMaxKeyValueSize() - Method in class org.apache.hadoop.hbase.client.ConnectionConfiguration
- getMaxMasterTimeout(Configuration, SnapshotProtos.SnapshotDescription.Type, long) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
- getMaxMemStoreTS() - Method in class org.apache.hadoop.hbase.regionserver.HStore
- getMaxMemStoreTS() - Method in class org.apache.hadoop.hbase.regionserver.HStoreFile
- getMaxMemStoreTS() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Returns The maximum memstoreTS in all store files.
- getMaxMemStoreTS() - Method in interface org.apache.hadoop.hbase.regionserver.StoreFile
-
Get max of the MemstoreTS in the KV's in this store file.
- getMaxMemStoreTSInList(Collection<HStoreFile>) - Static method in class org.apache.hadoop.hbase.regionserver.StoreUtils
-
Return the largest memstoreTS found across all storefiles in the given list.
- getMaxMerge() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- getMaxMultiSizeLimit() - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
Returns the maximum size (in bytes) that should be included in any single multi() call.
- getMaxOverlapsToSideline() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- getMaxPoolSize() - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
- getMaxPoolSize() - Method in interface org.apache.hadoop.hbase.thrift.IncrementCoalescerMBean
- getMaxPriority() - Method in class org.apache.hadoop.hbase.client.RowMutations
- getMaxQueueSize() - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
- getMaxQueueSize() - Method in interface org.apache.hadoop.hbase.thrift.IncrementCoalescerMBean
- getMaxRegions(NamespaceDescriptor) - Static method in class org.apache.hadoop.hbase.master.TableNamespaceManager
- getMaxRegionSequenceId(Configuration, RegionInfo, IOExceptionSupplier<FileSystem>, IOExceptionSupplier<FileSystem>) - Static method in class org.apache.hadoop.hbase.wal.WALSplitUtil
-
Deprecated.Only for compatibility, will be removed in 4.0.0.
- getMaxRegionSequenceId(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.wal.WALSplitUtil
-
Get the max sequence id which is stored in the region directory.
- getMaxResultSize() - Method in class org.apache.hadoop.hbase.client.ImmutableScan
- getMaxResultSize() - Method in class org.apache.hadoop.hbase.client.Scan
-
Returns the maximum result size in bytes.
- getMaxResultSize() - Method in interface org.apache.hadoop.hbase.quotas.OperationQuota
-
Returns the maximum result size to be returned by the given operation.
- getMaxResultSize() - Method in interface org.apache.hadoop.hbase.regionserver.RegionScanner
- getMaxResultsPerColumnFamily() - Method in class org.apache.hadoop.hbase.client.Get
-
Method for retrieving the get's maximum number of values to return per Column Family
- getMaxResultsPerColumnFamily() - Method in class org.apache.hadoop.hbase.client.ImmutableScan
- getMaxResultsPerColumnFamily() - Method in class org.apache.hadoop.hbase.client.Scan
-
Returns maximum number of values to return per row per CF
- getMaxSequenceId() - Method in class org.apache.hadoop.hbase.regionserver.HStore
- getMaxSequenceId() - Method in class org.apache.hadoop.hbase.regionserver.HStoreFile
- getMaxSequenceId() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Returns The maximum sequence id in all store files.
- getMaxSequenceId() - Method in interface org.apache.hadoop.hbase.regionserver.StoreFile
-
Returns This files maximum edit sequence id.
- getMaxSequenceIdInList(Collection<HStoreFile>) - Static method in class org.apache.hadoop.hbase.regionserver.StoreUtils
-
Return the highest sequence ID found across all storefiles in the given list.
- getMaxSize() - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCache
-
Returns the Max size of the block cache, in bytes.
- getMaxSize() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
- getMaxSize() - Method in class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache
-
Get the maximum size of this cache.
- getMaxSize() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
Get the maximum size of this cache.
- getMaxSize() - Method in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
- getMaxSize() - Method in class org.apache.hadoop.hbase.io.hfile.TinyLfuBlockCache
- getMaxSleepTime() - Method in class org.apache.hadoop.hbase.util.RetryCounter.RetryConfig
- getMaxSplitImbalance() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreConfig
- getMaxStoreFileAge() - Method in class org.apache.hadoop.hbase.regionserver.HStore
- getMaxStoreFileAge() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Returns Max age of store files hosted on this region server
- getMaxStoreFileAge() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
-
Returns Max age of store files under this region
- getMaxStoreFileAge() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
- getMaxStoreFileAge() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Returns Max age of store files in this store
- getMaxStoreFileAge(String) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregate
-
Returns Max age of store files for this table
- getMaxStoreFileAge(String) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImpl
- getMaxStoreFiles() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the max number of store files across all regions of this region server.
- getMaxStoreFiles(String) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregate
-
Get the max number of store files across all regions of this table
- getMaxStoreFiles(String) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImpl
- getMaxStoreSeqId() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
- getMaxStoreSeqId() - Method in interface org.apache.hadoop.hbase.regionserver.Region
- getMaxTables(NamespaceDescriptor) - Static method in class org.apache.hadoop.hbase.master.TableNamespaceManager
- getMaxThroughput() - Method in class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareThroughputController
- getMaxTime() - Method in class org.apache.hadoop.hbase.errorhandling.TimeoutExceptionInjector
- getMaxTimestamp() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileReader
- getMaxValue() - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
-
returns the maximum value for this type T
- getMaxValues() - Method in class org.apache.hadoop.hbase.rest.RowSpec
- getMaxVersions() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Returns maximum number of versions
- getMaxVersions() - Method in class org.apache.hadoop.hbase.client.Get
-
Method for retrieving the get's maximum number of version
- getMaxVersions() - Method in class org.apache.hadoop.hbase.client.ImmutableScan
- getMaxVersions() - Method in class org.apache.hadoop.hbase.client.Scan
-
Returns the max number of versions to fetch
- getMaxVersions() - Method in class org.apache.hadoop.hbase.regionserver.CustomizedScanInfoBuilder
- getMaxVersions() - Method in class org.apache.hadoop.hbase.regionserver.ScanInfo
- getMaxVersions() - Method in interface org.apache.hadoop.hbase.regionserver.ScanOptions
- getMaxVersions() - Method in class org.apache.hadoop.hbase.regionserver.StoreContext
- getMaxVersions() - Method in class org.apache.hadoop.hbase.rest.RowSpec
- getMBeanAttributeInfo(ObjectName) - Static method in class org.apache.hadoop.hbase.util.JSONMetricUtil
- getMD5AsHex(byte[]) - Static method in class org.apache.hadoop.hbase.util.MD5Hash
-
Given a byte array, returns in MD5 hash as a hex string.
- getMD5AsHex(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.MD5Hash
-
Given a byte array, returns its MD5 hash as a hex string.
- getMean() - Method in class org.apache.hadoop.hbase.io.hfile.AgeSnapshot
- getMean() - Method in interface org.apache.hadoop.hbase.metrics.Snapshot
-
Returns the arithmetic mean of the values in the snapshot.
- getMean() - Method in class org.apache.hadoop.hbase.util.RollingStatCalculator
-
Returns mean of the data values that are in the current list of data values
- getMeanRate() - Method in interface org.apache.hadoop.hbase.metrics.Meter
-
Returns the mean rate at which events have occurred since the meter was created.
- getMechanismName() - Method in enum class org.apache.hadoop.hbase.security.AuthMethod
-
Return the SASL mechanism name
- getMedian() - Method in interface org.apache.hadoop.hbase.metrics.Snapshot
-
Returns the median value in the distribution.
- getMemoryPools() - Static method in class org.apache.hadoop.hbase.util.JSONMetricUtil
- getMemStoreDataSize() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
- getMemStoreDataSize() - Method in interface org.apache.hadoop.hbase.regionserver.Region
- getMemStoreFlusher() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
- getMemStoreFlushSize() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
Returns the size of the memstore after which a flush to filesystem is triggered.
- getMemStoreFlushSize() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
- getMemStoreFlushSize() - Method in class org.apache.hadoop.hbase.regionserver.HStore
- getMemStoreFlushSize() - Method in class org.apache.hadoop.hbase.regionserver.RegionServicesForStores
- getMemStoreFlushSize() - Method in interface org.apache.hadoop.hbase.regionserver.StoreConfigInformation
-
Returns Gets the Memstore flush size for the region that this store works with.
- getMemStoreHeapSize() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
- getMemStoreHeapSize() - Method in interface org.apache.hadoop.hbase.regionserver.Region
- getMemStoreLimit() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the limit size of the off heap memstore (if enabled), otherwise get the limit size of the on heap memstore.
- getMemStoreLoad() - Method in class org.apache.hadoop.hbase.client.RegionLoadStats
- getMemStoreLoadPercent() - Method in class org.apache.hadoop.hbase.client.backoff.ServerStatistics.RegionStatistics
- getMemStoreOffHeapSize() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
- getMemStoreOffHeapSize() - Method in interface org.apache.hadoop.hbase.regionserver.Region
- getMemstoreOnlyRowReadsCount() - Method in class org.apache.hadoop.hbase.regionserver.HStore
- getMemstoreOnlyRowReadsCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
-
Returns the number of row reads completely on memstore per store
- getMemstoreOnlyRowReadsCount() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
- getMemstoreOnlyRowReadsCount() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Returns the number of read requests purely from the memstore.
- getMemstoreOnlyRowReadsCount(String) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregate
-
Returns number of row reads completely from memstore per store for this table
- getMemstoreOnlyRowReadsCount(String) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImpl
- getMemStoreSize() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
Returns the memstore size
- getMemStoreSize() - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerResult
- getMemStoreSize() - Method in class org.apache.hadoop.hbase.regionserver.HStore
- getMemStoreSize() - Method in interface org.apache.hadoop.hbase.regionserver.MemStoreSizing
- getMemStoreSize() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreSnapshot
- getMemStoreSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the size of the memstore on this region server.
- getMemStoreSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
-
Get the size of the memstore on this region server.
- getMemStoreSize() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
- getMemStoreSize() - Method in class org.apache.hadoop.hbase.regionserver.Segment
- getMemStoreSize() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Returns The size of this store's memstore.
- getMemStoreSize(String) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregate
-
Get the memory store size against this table
- getMemStoreSize(String) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImpl
- getMergeMetrics() - Method in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
-
Returns
OperationMetrics
containing common metrics for merge operation - getMergeMetrics() - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManagerSourceImpl
- getMergePlanCount() - Method in interface org.apache.hadoop.hbase.master.MetricsMasterWrapper
-
Get the number of region merge plans executed.
- getMergePlanCount() - Method in class org.apache.hadoop.hbase.master.MetricsMasterWrapperImpl
- getMergeProcMetrics() - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManager
-
Returns Set of common metrics for merge procedure
- getMergeRegions(Cell[]) - Static method in class org.apache.hadoop.hbase.CatalogFamilyFormat
-
Returns Deserialized regioninfo values taken from column values that match the regex 'info:merge.*' in array of
cells
. - getMergeRegionsWithName(Cell[]) - Static method in class org.apache.hadoop.hbase.CatalogFamilyFormat
-
Returns Deserialized values of <qualifier,regioninfo> pairs taken from column values that match the regex 'info:merge.*' in array of
cells
. - getMergingAction() - Method in class org.apache.hadoop.hbase.regionserver.AdaptiveMemStoreCompactionStrategy
- getMergingAction() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreCompactionStrategy
- getMessage() - Method in exception org.apache.hadoop.hbase.backup.FailedArchiveException
- getMessage() - Method in exception org.apache.hadoop.hbase.exceptions.RegionMovedException
- getMessage() - Method in exception org.apache.hadoop.hbase.quotas.SpaceLimitingException
- getMessage() - Method in class org.apache.hadoop.hbase.tool.coprocessor.CoprocessorViolation
- getMetaBlock(String, boolean) - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
- getMetaBlock(String, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
- getMetaBlockIndexReader() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
- getMetaBlockIndexReader() - Method in class org.apache.hadoop.hbase.io.hfile.HFileInfo
- getMetaBlockIndexReader() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
- getMetaCacheMisses() - Method in class org.apache.hadoop.hbase.client.MetricsConnection
- getMetaCacheNumClearRegion() - Method in class org.apache.hadoop.hbase.client.MetricsConnection
-
metaCacheNumClearRegion metric
- getMetaCacheNumClearServer() - Method in class org.apache.hadoop.hbase.client.MetricsConnection
-
metaCacheNumClearServer metric
- getMetaData(ByteBuffer) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
For use by bucketcache.
- getMetadataValue(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.HStoreFile
- getMetaEntry() - Method in class org.apache.hadoop.hbase.util.HbckRegionInfo
- getMetaHitCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
- getMetaHitCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
- getMetaHitCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
- getMetaHTable(Connection) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Callers should call close on the returned
Table
instance. - getMetaIndexCount() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
- getMetaKeyForRegion(RegionInfo) - Static method in class org.apache.hadoop.hbase.CatalogFamilyFormat
-
Returns the row key to use for this regionInfo
- getMetaLocations() - Method in interface org.apache.hadoop.hbase.client.ConnectionRegistryEndpoint
-
Get the location of meta regions.
- getMetaLocations() - Method in class org.apache.hadoop.hbase.master.HMaster
- getMetaLocations() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
- getMetaLocationSyncer() - Method in class org.apache.hadoop.hbase.master.HMaster
- getMetaLocationSyncer() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Get the meta location syncer.
- getMetaMissCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
- getMetaMissCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
- getMetaMissCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
- getMetaOperationTimeout() - Method in class org.apache.hadoop.hbase.client.ConnectionConfiguration
- getMetaPriorityQueueLength() - Method in class org.apache.hadoop.hbase.ipc.DelegatingRpcScheduler
- getMetaPriorityQueueLength() - Method in class org.apache.hadoop.hbase.ipc.FifoRpcScheduler
- getMetaPriorityQueueLength() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapper
- getMetaPriorityQueueLength() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapperImpl
- getMetaPriorityQueueLength() - Method in class org.apache.hadoop.hbase.ipc.RpcScheduler
-
Retrieves length of the meta priority queue for metrics.
- getMetaPriorityQueueLength() - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
- getMetaReadRpcTimeout() - Method in class org.apache.hadoop.hbase.client.ConnectionConfiguration
- getMetaRegionLocation(ZKWatcher) - Static method in class org.apache.hadoop.hbase.zookeeper.MetaTableLocator
-
Gets the meta region location, if available.
- getMetaRegionLocation(ZKWatcher, int) - Static method in class org.apache.hadoop.hbase.zookeeper.MetaTableLocator
-
Gets the meta region location, if available.
- getMetaRegionLocationCache() - Method in class org.apache.hadoop.hbase.HBaseServerBase
- getMetaRegionLocations() - Method in class org.apache.hadoop.hbase.client.MasterRegistry
- getMetaRegionLocations() - Method in interface org.apache.hadoop.hbase.client.ConnectionRegistry
-
Get the location of meta region(s).
- getMetaRegionLocations() - Method in class org.apache.hadoop.hbase.MetaRegionLocationCache
-
Returns Optional list of HRegionLocations for meta replica(s), null if the cache is empty.
- getMetaRegionLocations(RpcController, RegistryProtos.GetMetaRegionLocationsRequest) - Method in class org.apache.hadoop.hbase.HBaseRpcServicesBase
- getMetaRegionState(ZKWatcher) - Static method in class org.apache.hadoop.hbase.zookeeper.MetaTableLocator
-
Load the meta region state from the meta server ZNode.
- getMetaRegionState(ZKWatcher, int) - Static method in class org.apache.hadoop.hbase.zookeeper.MetaTableLocator
-
Load the meta region state from the meta region server ZNode.
- getMetaReplicaCallTimeoutMicroSecondScan() - Method in class org.apache.hadoop.hbase.client.ConnectionConfiguration
- getMetaReplicaIdFromPath(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZNodePaths
-
Parses the meta replicaId from the passed path.
- getMetaReplicaIdFromZNode(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZNodePaths
-
Parse the meta replicaId from the passed znode
- getMetaReplicaNodes() - Method in class org.apache.hadoop.hbase.zookeeper.ZKWatcher
-
Get the znodes corresponding to the meta replicas from ZK
- getMetaReplicaNodesAndWatchChildren() - Method in class org.apache.hadoop.hbase.zookeeper.ZKWatcher
-
Same as
ZKWatcher.getMetaReplicaNodes()
except that this also registers a watcher on base znode for subsequent CREATE/DELETE operations on child nodes. - getMetaRSPort(Connection) - Static method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- getMetaTableRows() - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Returns all rows from the hbase:meta table.
- getMetaTableRows(TableName) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Returns all rows from the hbase:meta table for a given user table
- getMetaWriter() - Method in class org.apache.hadoop.hbase.io.hfile.CompoundBloomFilterWriter
- getMetaWriter() - Method in interface org.apache.hadoop.hbase.util.BloomFilterWriter
-
Get a writable interface into bloom filter meta data.
- getMeter() - Method in interface org.apache.hadoop.hbase.metrics.Timer
- getMethod() - Method in class org.apache.hadoop.hbase.client.RegionCoprocessorServiceExec
- getMethod() - Method in interface org.apache.hadoop.hbase.ipc.RpcCall
-
Returns The service method.
- getMethod() - Method in class org.apache.hadoop.hbase.ipc.ServerCall
- getMethodDescriptor(String, Descriptors.ServiceDescriptor) - Static method in class org.apache.hadoop.hbase.ipc.CoprocessorRpcUtils
- getMethodName() - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord
- getMetricRegistries() - Method in class org.apache.hadoop.hbase.metrics.MetricRegistries
-
Returns MetricRegistry's created.
- getMetricRegistryForMaster() - Method in interface org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment
-
Returns a MetricRegistry that can be used to track metrics at the master level.
- getMetricRegistryForRegionServer() - Method in interface org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment
-
Returns a MetricRegistry that can be used to track metrics at the region server level.
- getMetricRegistryForRegionServer() - Method in interface org.apache.hadoop.hbase.coprocessor.RegionServerCoprocessorEnvironment
-
Returns a MetricRegistry that can be used to track metrics at the region server level.
- getMetricRegistryForRegionServer() - Method in interface org.apache.hadoop.hbase.coprocessor.WALCoprocessorEnvironment
-
Returns a MetricRegistry that can be used to track metrics at the region server level.
- getMetricRegistryInfo() - Method in interface org.apache.hadoop.hbase.metrics.BaseSource
- getMetricRegistryInfo() - Method in interface org.apache.hadoop.hbase.metrics.MetricRegistry
-
Return the MetricRegistryInfo object for this registry.
- getMetricRegistryInfo() - Method in class org.apache.hadoop.hbase.regionserver.metrics.MetricsTableRequests
- getMetricRegistryInfos() - Method in class org.apache.hadoop.hbase.metrics.MetricRegistries
-
Returns MetricRegistryInfo's for the MetricRegistry's created.
- getMetrics() - Method in class org.apache.hadoop.hbase.ipc.RpcServer
-
Returns the metrics instance for reporting RPC call statistics
- getMetrics() - Method in interface org.apache.hadoop.hbase.ipc.RpcServerInterface
-
Returns the metrics instance for reporting RPC call statistics
- getMetrics() - Method in interface org.apache.hadoop.hbase.metrics.MetricSet
-
A map of metric names to metrics.
- getMetrics() - Method in class org.apache.hadoop.hbase.MockRegionServerServices
- getMetrics() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
- getMetrics() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
- getMetrics() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
Returns the metrics tracker for the region server
- getMetrics() - Method in class org.apache.hadoop.hbase.regionserver.ScannerContext
-
Get the metrics instance.
- getMetrics() - Method in class org.apache.hadoop.hbase.replication.ReplicationEndpoint.Context
- getMetrics(MetricsCollector, boolean) - Method in class org.apache.hadoop.hbase.io.MetricsIOSourceImpl
- getMetrics(MetricsCollector, boolean) - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceImpl
- getMetrics(MetricsCollector, boolean) - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManagerSourceImpl
- getMetrics(MetricsCollector, boolean) - Method in class org.apache.hadoop.hbase.master.MetricsMasterProcSourceImpl
- getMetrics(MetricsCollector, boolean) - Method in class org.apache.hadoop.hbase.master.MetricsMasterQuotaSourceImpl
- getMetrics(MetricsCollector, boolean) - Method in class org.apache.hadoop.hbase.master.MetricsMasterSourceImpl
- getMetrics(MetricsCollector, boolean) - Method in class org.apache.hadoop.hbase.metrics.BaseSourceImpl
- getMetrics(MetricsCollector, boolean) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionAggregateSourceImpl
-
Yes this is a get function that doesn't return anything.
- getMetrics(MetricsCollector, boolean) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
-
Yes this is a get function that doesn't return anything.
- getMetrics(MetricsCollector, boolean) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableAggregateSourceImpl
-
Yes this is a get function that doesn't return anything.
- getMetrics(MetricsCollector, boolean) - Method in class org.apache.hadoop.hbase.regionserver.MetricsUserAggregateSourceImpl
- getMetrics(MetricsCollector, boolean) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsUserSource
- getMetrics(MetricsCollector, boolean) - Method in class org.apache.hadoop.hbase.regionserver.MetricsUserSourceImpl
- getMetrics(MetricsCollector, boolean) - Method in class org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSourceImpl
- getMetricsContext() - Method in interface org.apache.hadoop.hbase.metrics.BaseSource
-
Get the metrics context.
- getMetricsContext() - Method in class org.apache.hadoop.hbase.metrics.BaseSourceImpl
- getMetricsContext() - Method in class org.apache.hadoop.hbase.metrics.MetricRegistryInfo
-
Get the metrics context.
- getMetricScope() - Method in class org.apache.hadoop.hbase.client.MetricsConnection
-
scope of the metrics object
- getMetricsDescription() - Method in interface org.apache.hadoop.hbase.metrics.BaseSource
-
Get the description of what this source exposes.
- getMetricsDescription() - Method in class org.apache.hadoop.hbase.metrics.BaseSourceImpl
- getMetricsDescription() - Method in class org.apache.hadoop.hbase.metrics.MetricRegistryInfo
-
Get the description of what this source exposes.
- getMetricsJmxContext() - Method in interface org.apache.hadoop.hbase.metrics.BaseSource
-
Get the name of the context in JMX that this source will be exposed through.
- getMetricsJmxContext() - Method in class org.apache.hadoop.hbase.metrics.BaseSourceImpl
- getMetricsJmxContext() - Method in class org.apache.hadoop.hbase.metrics.MetricRegistryInfo
-
Get the name of the context in JMX that this source will be exposed through.
- getMetricsName() - Method in interface org.apache.hadoop.hbase.metrics.BaseSource
-
Get the name of the metrics that are being exported by this source.
- getMetricsName() - Method in class org.apache.hadoop.hbase.metrics.BaseSourceImpl
- getMetricsName() - Method in class org.apache.hadoop.hbase.metrics.MetricRegistryInfo
-
Get the name of the metrics that are being exported by this source.
- getMetricsProcSource() - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManager
- getMetricsProcSource() - Method in class org.apache.hadoop.hbase.master.MetricsMaster
- getMetricsQuotaSource() - Method in class org.apache.hadoop.hbase.master.MetricsMaster
- getMetricsRegistry() - Method in class org.apache.hadoop.hbase.metrics.BaseSourceImpl
- getMetricsSource() - Method in class org.apache.hadoop.hbase.io.MetricsIO
- getMetricsSource() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServer
- getMetricsSource() - Method in class org.apache.hadoop.hbase.master.MetricsMaster
- getMetricsSource() - Method in class org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManager
- getMetricsSource() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
- getMetricsSource() - Method in class org.apache.hadoop.hbase.util.JvmPauseMonitor
- getMetricsTableRequests() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
- getMetricsUserAggregate() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
- getMetricsUserAggregate(Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.MetricsUserAggregateFactory
- getMidKeyMetadata() - Method in interface org.apache.hadoop.hbase.io.hfile.BlockIndexChunk
- getMidpoint(CellComparator, ExtendedCell, ExtendedCell) - Static method in class org.apache.hadoop.hbase.io.hfile.HFileWriterImpl
-
Try to return a Cell that falls between
left
andright
but that is shorter; i.e. - getMin() - Method in class org.apache.hadoop.hbase.filter.TimestampsFilter
-
Gets the minimum timestamp requested by filter.
- getMin() - Method in class org.apache.hadoop.hbase.io.hfile.AgeSnapshot
- getMin() - Method in class org.apache.hadoop.hbase.io.TimeRange
-
Returns the smallest timestamp that should be considered
- getMin() - Method in interface org.apache.hadoop.hbase.metrics.Snapshot
-
Returns the lowest value in the snapshot.
- getMin() - Method in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker
-
Returns the minimumTimestamp
- getMin() - Method in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker.NonSyncTimeRangeTracker
- getMin() - Method in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker.SyncTimeRangeTracker
- getMinBlockSizeBytes() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
- getMinBlockSizeBytes() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
The minimum block size configuration from all relevant column families.
- getMinColumn() - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
-
Returns the min column range for the filter
- getMinColumnInclusive() - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
-
Returns true if min column is inclusive, false otherwise
- getMiniHBaseCluster() - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- getMinimumTimestamp() - Method in class org.apache.hadoop.hbase.regionserver.HStoreFile
- getMinimumTimestamp() - Method in interface org.apache.hadoop.hbase.regionserver.StoreFile
-
Get the min timestamp of all the cells in the store file.
- getMinIndexNumEntries(Configuration) - Static method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex
- getMinorCompactionCompressionType() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Returns Compression type setting for minor compactions.
- getMinorVersion() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
Returns the minor version of this HFile format
- getMinorVersion() - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterImpl
- getMinSequenceId() - Method in class org.apache.hadoop.hbase.regionserver.CompactionPipeline
- getMinSequenceId() - Method in class org.apache.hadoop.hbase.regionserver.CompositeImmutableSegment
- getMinSequenceId() - Method in class org.apache.hadoop.hbase.regionserver.Segment
- getMinStoreFileAge() - Method in class org.apache.hadoop.hbase.regionserver.HStore
- getMinStoreFileAge() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Returns Min age of store files hosted on this region server
- getMinStoreFileAge() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
-
Returns Min age of store files under this region
- getMinStoreFileAge() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
- getMinStoreFileAge() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Returns Min age of store files in this store
- getMinStoreFileAge(String) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregate
-
Returns Min age of store files for this table
- getMinStoreFileAge(String) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImpl
- getMinValue() - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
- getMinVersions() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Returns The minimum number of versions to keep.
- getMinVersions() - Method in class org.apache.hadoop.hbase.regionserver.CustomizedScanInfoBuilder
- getMinVersions() - Method in class org.apache.hadoop.hbase.regionserver.ScanInfo
- getMinVersions() - Method in interface org.apache.hadoop.hbase.regionserver.ScanOptions
- getMissCachingCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
- getMissCachingCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
- getMissCachingRatio() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
- getMissCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
- getMissCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
- getMissCount() - Method in class org.apache.hadoop.hbase.mob.MobFileCache
-
Gets the count of misses to the mob file cache.
- getMissedMobFiles() - Method in class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
- getMissing() - Method in class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
- getMissingLogsCount() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
-
Returns the number of missing log files
- getMissingStoreFilesCount() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
-
Returns the number of missing store files
- getMissRatio() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
- getMixedRowReadsCount() - Method in class org.apache.hadoop.hbase.regionserver.HStore
- getMixedRowReadsCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
-
Returns the number of row reads on memstore and file per store
- getMixedRowReadsCount() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
- getMixedRowReadsCount() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Returns the number of read requests from the files under this store.
- getMixedRowReadsCount(String) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregate
-
Returns number of row reads from file and memstore per store for this table
- getMixedRowReadsCount(String) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImpl
- getMobColumnFamilies(TableDescriptor) - Static method in class org.apache.hadoop.hbase.mob.MobUtils
-
Get list of Mob column families (if any exists)
- getMobCompactionState(TableName) - Method in class org.apache.hadoop.hbase.master.HMaster
-
Gets the mob file compaction state for a specific table.
- getMobCompactPartitionPolicy() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Get the mob compact partition policy for this family
- getMobFamilyPath(Configuration, TableName, String) - Static method in class org.apache.hadoop.hbase.mob.MobUtils
-
Gets the family dir of the mob files.
- getMobFamilyPath(Path, String) - Static method in class org.apache.hadoop.hbase.mob.MobUtils
-
Gets the family dir of the mob files.
- getMobFileCache() - Method in class org.apache.hadoop.hbase.MockRegionServerServices
- getMobFileCache() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
- getMobFileCache() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
May be null if this is a master which not carry table.
- getMobFileCache() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
Returns The cache for mob files.
- getMobFileCacheAccessCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Gets the count of accesses to the mob file cache.
- getMobFileCacheCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Gets the count of cached mob files.
- getMobFileCacheEvictedCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Gets the number of items evicted from the mob file cache.
- getMobFileCacheHitPercent() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Gets the hit percent to the mob file cache.
- getMobFileCacheMissCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Gets the count of misses to the mob file cache.
- getMobFileName(Cell) - Static method in class org.apache.hadoop.hbase.mob.MobUtils
-
Gets the mob file name from the mob ref cell.
- getMobFilesChecked() - Method in class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
-
Returns number of mob files checked in the last HfileCorruptionChecker run
- getMobFlushCount() - Method in class org.apache.hadoop.hbase.regionserver.HMobStore
- getMobFlushCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Gets the number of the flushes in mob-enabled stores.
- getMobFlushedCellsCount() - Method in class org.apache.hadoop.hbase.regionserver.HMobStore
- getMobFlushedCellsCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Gets the number of mob cells flushed to disk.
- getMobFlushedCellsSize() - Method in class org.apache.hadoop.hbase.regionserver.HMobStore
- getMobFlushedCellsSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Gets the total amount of mob cells flushed to disk, in bytes.
- getMobHome(Configuration) - Static method in class org.apache.hadoop.hbase.mob.MobUtils
-
Gets the root dir of the mob files.
- getMobHome(Path) - Static method in class org.apache.hadoop.hbase.mob.MobUtils
-
Gets the root dir of the mob files under the qualified HBase root dir.
- getMobPath() - Method in class org.apache.hadoop.hbase.io.HFileLink
-
Returns the path of the mob hfiles.
- getMobRegionInfo(TableName) - Static method in class org.apache.hadoop.hbase.mob.MobUtils
-
Gets the RegionInfo of the mob files.
- getMobRegionPath(Configuration, TableName) - Static method in class org.apache.hadoop.hbase.mob.MobUtils
-
Gets the region dir of the mob files.
- getMobRegionPath(Path, TableName) - Static method in class org.apache.hadoop.hbase.mob.MobUtils
-
Gets the region dir of the mob files under the specified root dir.
- getMobScanCellsCount() - Method in class org.apache.hadoop.hbase.regionserver.HMobStore
- getMobScanCellsCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Gets the number of scanned mob cells.
- getMobScanCellsSize() - Method in class org.apache.hadoop.hbase.regionserver.HMobStore
- getMobScanCellsSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Gets the total amount of scanned mob cells, in bytes.
- getMobStoreFilePercentage() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
-
Returns the percentage of the mob store files
- getMobStoreFilesCount() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
-
Returns the number of available store files in the mob dir
- getMobStoreFilesSize() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
-
Returns the total size of the store files in the mob store
- getMobTableDir(Configuration, TableName) - Static method in class org.apache.hadoop.hbase.mob.MobUtils
- getMobTableDir(Path, TableName) - Static method in class org.apache.hadoop.hbase.mob.MobUtils
-
Gets the table dir of the mob files under the qualified HBase root dir.
- getMobThreshold() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Gets the mob threshold of the family.
- getMobValueLength(Cell) - Static method in class org.apache.hadoop.hbase.mob.MobUtils
-
Gets the mob value length from the mob ref cell.
- getModificationTime() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
Returns Get the modification time of the file.
- getModificationTimestamp() - Method in class org.apache.hadoop.hbase.regionserver.HStoreFile
- getModificationTimestamp() - Method in interface org.apache.hadoop.hbase.regionserver.StoreFile
-
Get the modification time of this store file.
- getModifiersField() - Static method in class org.apache.hadoop.hbase.util.ReflectionUtils
- getModTime() - Method in class org.apache.hadoop.hbase.util.HbckRegionInfo
- getMostRecentPosition() - Method in class org.apache.hadoop.hbase.util.WindowMovingAverage
-
Returns index of most recent
- getMovedRegion(String) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
- getMoveMetrics() - Method in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
-
Returns
OperationMetrics
containing common metrics for move region operation - getMoveMetrics() - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManagerSourceImpl
- getMoveProcMetrics() - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManager
-
Returns Set of common metrics for move procedure
- getMovesCalculated() - Method in class org.apache.hadoop.hbase.client.BalanceResponse
-
The number of moves calculated by the balancer if
BalanceResponse.isBalancerRan()
is true. - getMovesExecuted() - Method in class org.apache.hadoop.hbase.client.BalanceResponse
-
The number of moves actually executed by the balancer if it ran.
- getMsgInterval() - Method in class org.apache.hadoop.hbase.HBaseServerBase
- getMultiGetsCount() - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord
- getMultiMutationsCount() - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord
- getMultipleRowResource(String, String) - Method in class org.apache.hadoop.hbase.rest.TableResource
- getMultiServiceCalls() - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord
- getMultiTracker() - Method in class org.apache.hadoop.hbase.client.MetricsConnection
-
multiTracker metric
- getMutations() - Method in class org.apache.hadoop.hbase.client.RowMutations
-
Returns An unmodifiable list of the current mutations.
- getMutationsFromWALEntry(AdminProtos.WALEntry, ExtendedCellScanner, Pair<WALKey, WALEdit>, Durability) - Static method in class org.apache.hadoop.hbase.wal.WALSplitUtil
-
Deprecated.Since 3.0.0, will be removed in 4.0.0.
- getMvcc() - Method in class org.apache.hadoop.hbase.wal.WALKeyImpl
- getMVCC() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
- getMvccFromOperationContext(long, long) - Method in class org.apache.hadoop.hbase.regionserver.ServerNonceManager
-
Return the write point of the previous succeed operation.
- getMvccReadPoint() - Method in interface org.apache.hadoop.hbase.regionserver.RegionScanner
-
Returns The Scanner's MVCC readPt see
MultiVersionConcurrencyControl
- getMvccReadPoint(Scan) - Static method in class org.apache.hadoop.hbase.client.ClientInternalHelper
- getMyEphemeralNodeFileName() - Static method in class org.apache.hadoop.hbase.ZNodeClearer
-
Get the name of the file used to store the znode contents
- getName() - Method in interface org.apache.hadoop.hbase.client.AsyncBufferedMutator
-
Gets the fully qualified table name instance of the table that this
AsyncBufferedMutator
writes to. - getName() - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
Gets the fully qualified table name instance of this table.
- getName() - Method in interface org.apache.hadoop.hbase.client.AsyncTableRegionLocator
-
Gets the fully qualified table name instance of the table whose region we want to locate.
- getName() - Method in interface org.apache.hadoop.hbase.client.BufferedMutator
-
Gets the fully qualified table name instance of the table that this BufferedMutator writes to.
- getName() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Returns a copy of Name of this column family
- getName() - Method in interface org.apache.hadoop.hbase.client.RegionLocator
-
Gets the fully qualified table name instance of this table.
- getName() - Method in enum class org.apache.hadoop.hbase.client.security.SecurityCapability
- getName() - Method in class org.apache.hadoop.hbase.client.SnapshotDescription
- getName() - Method in interface org.apache.hadoop.hbase.client.Table
-
Gets the fully qualified table name instance of this table.
- getName() - Method in class org.apache.hadoop.hbase.errorhandling.ForeignExceptionDispatcher
- getName() - Method in enum class org.apache.hadoop.hbase.io.compress.Compression.Algorithm
- getName() - Method in class org.apache.hadoop.hbase.io.crypto.aes.AES
- getName() - Method in class org.apache.hadoop.hbase.io.crypto.aes.CommonsCryptoAES
- getName() - Method in class org.apache.hadoop.hbase.io.crypto.Cipher
-
Return this Cipher's name
- getName() - Method in interface org.apache.hadoop.hbase.io.crypto.CipherProvider
-
Return the provider's name
- getName() - Method in class org.apache.hadoop.hbase.io.crypto.CryptoCipherProvider
- getName() - Method in class org.apache.hadoop.hbase.io.crypto.DefaultCipherProvider
- getName() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
-
Returns this reader's "name".
- getName() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
- getName() - Method in class org.apache.hadoop.hbase.ipc.RpcExecutor
- getName() - Method in class org.apache.hadoop.hbase.NamespaceDescriptor
- getName() - Method in class org.apache.hadoop.hbase.regionserver.AdaptiveMemStoreCompactionStrategy
- getName() - Method in class org.apache.hadoop.hbase.regionserver.BasicMemStoreCompactionStrategy
- getName() - Method in class org.apache.hadoop.hbase.regionserver.EagerMemStoreCompactionStrategy
- getName() - Method in exception org.apache.hadoop.hbase.regionserver.LeaseManager.LeaseStillHeldException
-
Returns name of lease
- getName() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreCompactionStrategy
- getName() - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
-
Get group name.
- getName() - Method in class org.apache.hadoop.hbase.ScheduledChore
- getName() - Method in class org.apache.hadoop.hbase.security.User
-
Returns the full user name.
- getName() - Method in class org.apache.hadoop.hbase.TableName
- getName() - Method in enum class org.apache.hadoop.hbase.util.ChecksumType
-
returns the name of this checksum type
- getName() - Method in enum class org.apache.hadoop.hbase.util.DNS.ServerType
- getName() - Method in class org.apache.hadoop.hbase.util.HbckTableInfo
- getNameAsString() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Returns Name of this column family
- getNameAsString() - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
- getNameAsString() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
Returns the region name as a string
- getNameAsString() - Method in class org.apache.hadoop.hbase.TableName
- getNameAsString() - Method in interface org.apache.hadoop.hbase.UserMetrics
-
Returns the user name as a string
- getNamedQueueEvent() - Method in class org.apache.hadoop.hbase.namequeues.NamedQueuePayload
- getNamedQueueEvent() - Method in class org.apache.hadoop.hbase.namequeues.request.NamedQueueGetRequest
- getNamedQueueEvent() - Method in class org.apache.hadoop.hbase.namequeues.response.NamedQueueGetResponse
- getNamedQueueRecorder() - Method in class org.apache.hadoop.hbase.HBaseServerBase
-
get NamedQueue Provider to add different logs to ringbuffer
- getNamedQueueRecords(NamedQueueGetRequest) - Method in class org.apache.hadoop.hbase.namequeues.impl.BalancerDecisionQueueService
- getNamedQueueRecords(NamedQueueGetRequest) - Method in class org.apache.hadoop.hbase.namequeues.impl.BalancerRejectionQueueService
- getNamedQueueRecords(NamedQueueGetRequest) - Method in class org.apache.hadoop.hbase.namequeues.impl.SlowLogQueueService
- getNamedQueueRecords(NamedQueueGetRequest) - Method in class org.apache.hadoop.hbase.namequeues.NamedQueueRecorder
-
Retrieve in memory queue records from ringbuffer
- getNamedQueueRecords(NamedQueueGetRequest) - Method in interface org.apache.hadoop.hbase.namequeues.NamedQueueService
-
Retrieve in memory queue records from ringbuffer
- getNamedQueueRecords(NamedQueueGetRequest) - Method in class org.apache.hadoop.hbase.namequeues.WALEventTrackerQueueService
- getNameForThrottling(HStore, String) - Static method in class org.apache.hadoop.hbase.regionserver.throttle.ThroughputControlUtil
-
Generate a name for throttling, to prevent name conflict when multiple IO operation running parallel on the same store.
- getNameFromId(short) - Static method in enum class org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
-
Find and return the name of data block encoder for the given id.
- getNameFromId(short) - Static method in enum class org.apache.hadoop.hbase.io.encoding.IndexBlockEncoding
-
Find and return the name of data block encoder for the given id.
- getNameInBytes() - Method in enum class org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
-
Returns name converted to bytes.
- getNameInBytes() - Method in enum class org.apache.hadoop.hbase.io.encoding.IndexBlockEncoding
-
Returns name converted to bytes.
- getNamespace() - Method in class org.apache.hadoop.hbase.client.NormalizeTableFilterParams
- getNamespace() - Method in class org.apache.hadoop.hbase.quotas.QuotaSettings
- getNamespace() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
-
Get the name of the namespace this table is in.
- getNamespace() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
- getNamespace() - Method in class org.apache.hadoop.hbase.TableName
- getNamespace(String) - Method in interface org.apache.hadoop.hbase.master.ClusterSchema
-
Get a Namespace
- getNamespaceAsString() - Method in class org.apache.hadoop.hbase.TableName
- getNamespaceDescriptor(String) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get a namespace descriptor by name.
- getNamespaceDescriptor(String) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Get a namespace descriptor by name
- getNamespaceDescriptor(RpcController, MasterProtos.GetNamespaceDescriptorRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- getNamespaceDir(Path, String) - Static method in class org.apache.hadoop.hbase.util.CommonFSUtils
-
Returns the
Path
object representing the namespace directory under path rootdir - getNamespaceFamilyDescForMeta(Configuration) - Static method in class org.apache.hadoop.hbase.util.FSTableDescriptors
- getNamespaceFilter() - Method in class org.apache.hadoop.hbase.quotas.QuotaFilter
-
Returns the Namespace filter regex
- getNamespaceFromRowKey(byte[]) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
- getNamespaceInstanceResource(String) - Method in class org.apache.hadoop.hbase.rest.NamespacesInstanceResource
-
Dispatch to NamespaceInstanceResource for getting list of tables.
- getNamespaceInstanceResource(String) - Method in class org.apache.hadoop.hbase.rest.NamespacesResource
-
Dispatch to NamespaceInstanceResource
- getNamespaceLimiter(String) - Method in class org.apache.hadoop.hbase.quotas.QuotaCache
-
Returns the limiter associated to the specified namespace.
- getNamespaceQuota(Connection, String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
- getNamespaceQuotaManager() - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
- getNamespaceQuotaSnapshots() - Method in class org.apache.hadoop.hbase.quotas.QuotaObserverChore
-
Returns an unmodifiable view over the current
SpaceQuotaSnapshot
objects for each HBase namespace with a quota defined. - getNamespaceResource() - Method in class org.apache.hadoop.hbase.rest.RootResource
- getNamespaceRowKey(String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
- getNamespaceRowKeyRegex(String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
- getNamespaces() - Method in interface org.apache.hadoop.hbase.master.ClusterSchema
-
Get all Namespaces
- getNamespaces() - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeer
-
Get replicable namespace set of this peer
- getNamespaces() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
- getNamespaces() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerImpl
- getNamespaceSnapshots(Connection) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
Returns a set of the names of all namespaces containing snapshot entries.
- getNamespaceSpaceUtilization() - Method in interface org.apache.hadoop.hbase.master.MetricsMasterWrapper
-
Gets the space usage and limit for each namespace.
- getNamespaceSpaceUtilization() - Method in class org.apache.hadoop.hbase.master.MetricsMasterWrapperImpl
- getNamespaceTableCfWALEntryFilter() - Method in class org.apache.hadoop.hbase.replication.BaseReplicationEndpoint
-
Returns a WALEntryFilter for checking replication per table and CF.
- getNameWithNamespaceInclAsString() - Method in class org.apache.hadoop.hbase.TableName
-
Ideally, getNameAsString should contain namespace within it, but if the namespace is default, it just returns the name.
- getNegativeResultsCount() - Method in class org.apache.hadoop.hbase.io.hfile.BloomFilterMetrics
-
Returns Current value for bloom negative results count
- getNegotiatedQop() - Method in class org.apache.hadoop.hbase.security.HBaseSaslRpcServer
- getNettyDirectMemoryUsage() - Static method in class org.apache.hadoop.hbase.util.DirectMemoryUtils
-
Returns the current amount of direct memory used by netty module.
- getNettyDmUsage() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapper
- getNettyDmUsage() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapperImpl
- getNewAssignmentPlan() - Method in class org.apache.hadoop.hbase.master.RegionPlacementMaintainer
- getNewExternalChunk(int) - Method in class org.apache.hadoop.hbase.regionserver.ImmutableMemStoreLAB
- getNewExternalChunk(int) - Method in interface org.apache.hadoop.hbase.regionserver.MemStoreLAB
- getNewExternalChunk(int) - Method in class org.apache.hadoop.hbase.regionserver.MemStoreLABImpl
- getNewExternalChunk(ChunkCreator.ChunkType) - Method in class org.apache.hadoop.hbase.regionserver.ImmutableMemStoreLAB
- getNewExternalChunk(ChunkCreator.ChunkType) - Method in interface org.apache.hadoop.hbase.regionserver.MemStoreLAB
- getNewExternalChunk(ChunkCreator.ChunkType) - Method in class org.apache.hadoop.hbase.regionserver.MemStoreLABImpl
- getNewSyncReplicationState() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerImpl
- getNewSyncReplicationStateNode(String) - Method in class org.apache.hadoop.hbase.replication.ZKReplicationPeerStorage
- getNewVersionBehavior() - Method in class org.apache.hadoop.hbase.regionserver.StoreContext
- getNextCallable(R, RegionInfo) - Method in interface org.apache.hadoop.hbase.client.AsyncTable.PartialResultCoprocessorCallback
-
Subclasses should implement this to tell AsyncTable whether the given response is "final" or whether the AsyncTable should send another request to the coprocessor to fetch more results from the given region.
- getNextCallable(R, RegionInfo) - Method in class org.apache.hadoop.hbase.client.NoopPartialResultCoprocessorCallback
- getNextCellHint(Cell) - Method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
- getNextCellHint(Cell) - Method in class org.apache.hadoop.hbase.filter.ColumnPrefixFilter
- getNextCellHint(Cell) - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
- getNextCellHint(Cell) - Method in class org.apache.hadoop.hbase.filter.Filter
-
If the filter returns the match code SEEK_NEXT_USING_HINT, then it should also tell which is the next key it must seek to.
- getNextCellHint(Cell) - Method in class org.apache.hadoop.hbase.filter.FilterBase
-
Filters that are not sure which key must be next seeked to, can inherit this implementation that, by default, returns a null Cell.
- getNextCellHint(Cell) - Method in class org.apache.hadoop.hbase.filter.FilterList
- getNextCellHint(Cell) - Method in class org.apache.hadoop.hbase.filter.FilterListWithAND
- getNextCellHint(Cell) - Method in class org.apache.hadoop.hbase.filter.FilterListWithOR
- getNextCellHint(Cell) - Method in class org.apache.hadoop.hbase.filter.FilterWrapper
- getNextCellHint(Cell) - Method in class org.apache.hadoop.hbase.filter.FuzzyRowFilter
- getNextCellHint(Cell) - Method in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
- getNextCellHint(Cell) - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter
- getNextCellHint(Cell) - Method in class org.apache.hadoop.hbase.filter.PrefixFilter
- getNextCellHint(Cell) - Method in class org.apache.hadoop.hbase.filter.TimestampsFilter
-
Pick the next cell that the scanner should seek to.
- getNextIndexedKey() - Method in class org.apache.hadoop.hbase.io.hfile.BlockWithScanInfo
- getNextIndexedKey() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
- getNextIndexedKey() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
-
Returns the next key in the index (the key to seek to the next block)
- getNextIndexedKey() - Method in class org.apache.hadoop.hbase.regionserver.KeyValueHeap
- getNextIndexedKey() - Method in interface org.apache.hadoop.hbase.regionserver.KeyValueScanner
- getNextIndexedKey() - Method in class org.apache.hadoop.hbase.regionserver.NonLazyKeyValueScanner
- getNextIndexedKey() - Method in class org.apache.hadoop.hbase.regionserver.SegmentScanner
- getNextIndexedKey() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
- getNextIndexedKey() - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
- getNextKeyHint(ExtendedCell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.CompactionScanQueryMatcher
- getNextKeyHint(ExtendedCell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher
-
Delegate to
Filter.getNextCellHint(Cell)
. - getNextKeyHint(ExtendedCell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.UserScanQueryMatcher
- getNextKeyToRead() - Method in class org.apache.hadoop.hbase.util.MultiThreadedReader.HBaseReaderThread
- getNextMode() - Method in class org.apache.hadoop.hbase.hbtop.mode.DrillDownInfo
- getNextQueue(CallRunner) - Method in interface org.apache.hadoop.hbase.ipc.QueueBalancer
-
Returns the index of the next queue to which a request should be inserted
- getNextQueue(CallRunner) - Method in class org.apache.hadoop.hbase.ipc.RandomQueueBalancer
- getNextRefillTime() - Method in class org.apache.hadoop.hbase.quotas.AverageIntervalRateLimiter
- getNextRefillTime() - Method in class org.apache.hadoop.hbase.quotas.FixedIntervalRateLimiter
- getNextRefillTime() - Method in class org.apache.hadoop.hbase.quotas.RateLimiter
- getNextRow(ExtendedCell, NavigableSet<ExtendedCell>) - Method in class org.apache.hadoop.hbase.regionserver.AbstractMemStore
- getNextRowOrNextColumn(ExtendedCell) - Method in interface org.apache.hadoop.hbase.regionserver.querymatcher.ColumnTracker
-
Retrieve the MatchCode for the next row or column
- getNextRowOrNextColumn(ExtendedCell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ExplicitColumnTracker
- getNextRowOrNextColumn(ExtendedCell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.NewVersionBehaviorTracker
- getNextRowOrNextColumn(ExtendedCell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanWildcardColumnTracker
- getNextSequenceId(WAL) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Method to safely get the next sequence number.
- getNoChecksumVerify() - Method in class org.apache.hadoop.hbase.backup.BackupInfo
- getNoChecksumVerify() - Method in class org.apache.hadoop.hbase.backup.BackupRequest
- getNode() - Method in class org.apache.hadoop.hbase.zookeeper.ZKNodeTracker
- getNode() - Method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.NodeAndData
-
Deprecated.
- getNodeName(String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Get the name of the current node from the specified fully-qualified path.
- getNonce() - Method in class org.apache.hadoop.hbase.client.Action
- getNonce() - Method in class org.apache.hadoop.hbase.util.NonceKey
- getNonce() - Method in interface org.apache.hadoop.hbase.wal.WALKey
-
Returns The nonce
- getNonce() - Method in class org.apache.hadoop.hbase.wal.WALKeyImpl
-
Returns The nonce
- getNonceGenerator() - Method in interface org.apache.hadoop.hbase.client.AsyncClusterConnection
-
Get the nonce generator for this connection.
- getNonceGroup() - Method in interface org.apache.hadoop.hbase.client.NonceGenerator
-
Returns the nonce group (client ID) of this client manager.
- getNonceGroup() - Method in class org.apache.hadoop.hbase.client.PerClientRandomNonceGenerator
- getNonceGroup() - Method in class org.apache.hadoop.hbase.util.NonceKey
- getNonceGroup() - Method in interface org.apache.hadoop.hbase.wal.WALKey
-
Returns The nonce group
- getNonceGroup() - Method in class org.apache.hadoop.hbase.wal.WALKeyImpl
-
Returns The nonce group
- getNonceManager() - Method in class org.apache.hadoop.hbase.MockRegionServerServices
- getNonceManager() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
- getNonceManager() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
Only required for "old" log replay; if it's removed, remove this.
- getNoneCompressor() - Static method in class org.apache.hadoop.hbase.regionserver.wal.WALCellCodec
- getNoneUncompressor() - Static method in class org.apache.hadoop.hbase.regionserver.wal.WALCellCodec
- getNonRootSize() - Method in interface org.apache.hadoop.hbase.io.hfile.BlockIndexChunk
- getNonSharedArchivedStoreFilesSize() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
- getNormalizerTargetRegionCount() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
Check if there is the target region count.
- getNormalizerTargetRegionSize() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
Check if there is the target region size.
- getNoSuchSnapshot() - Static method in class org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot
-
Returns a singleton that corresponds to no snapshot information.
- getNoVersionMap() - Method in class org.apache.hadoop.hbase.client.Result
-
Map of families to their most recent qualifiers and values.
- getNullResultsCount() - Method in class org.apache.hadoop.hbase.util.MultiThreadedReader
- getNumActionsPerServer() - Method in class org.apache.hadoop.hbase.client.MetricsConnection.CallStats
- getNumActionsPerServerHist() - Method in class org.apache.hadoop.hbase.client.MetricsConnection
-
numActionsPerServerHist metric
- getNumAlwaysStandByMasters() - Method in class org.apache.hadoop.hbase.StartMiniClusterOption
-
Deprecated.
- getNumAlwaysStandByMasters() - Method in class org.apache.hadoop.hbase.testing.TestingHBaseClusterOption
- getNumberOfChildren(ZKWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Get the number of children of the specified node.
- getNumberOfListeners() - Method in class org.apache.hadoop.hbase.zookeeper.ZKWatcher
-
Returns The number of currently registered listeners
- getNumberOfOnlineRegions() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
- getNumberOfRecoveredRegions() - Method in class org.apache.hadoop.hbase.wal.BoundedRecoveredHFilesOutputSink
- getNumberOfRunningProcess() - Method in class org.apache.hadoop.hbase.util.JVM
-
Workaround to get the current number of process running.
- getNumberOfStatistics() - Method in class org.apache.hadoop.hbase.util.WindowMovingAverage
-
Returns number of statistics
- getNumberOfTasksInProgress() - Method in interface org.apache.hadoop.hbase.client.RequestController
-
Returns The number of running task.
- getNumberOfThreads(JobContext) - Static method in class org.apache.hadoop.hbase.mapreduce.MultithreadedTableMapper
-
The number of threads in the thread pool that will run the map function.
- getNumBytesCompacted() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
- getNumBytesCompacted() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
- getNumChunks() - Method in class org.apache.hadoop.hbase.io.hfile.CompoundBloomFilter
- getNumCompactionsCompleted() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
- getNumCompactionsCompleted() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
- getNumCompactionsFailed() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
-
Returns the total number of compactions that have been reported as failed on this region.
- getNumCompactionsFailed() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
- getNumCompactionsQueued() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
-
Returns the total number of compactions that are currently queued(or being executed) at point in time
- getNumCompactionsQueued() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
- getNumDataIndexLevels() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
- getNumDataNodes() - Method in class org.apache.hadoop.hbase.StartMiniClusterOption
-
Deprecated.
- getNumDataNodes() - Method in class org.apache.hadoop.hbase.testing.TestingHBaseClusterOption
- getNumDeadRegionServers() - Method in interface org.apache.hadoop.hbase.master.MetricsMasterWrapper
-
Get the number of dead region servers
- getNumDeadRegionServers() - Method in class org.apache.hadoop.hbase.master.MetricsMasterWrapperImpl
- getNumDrainingRegionServers() - Method in interface org.apache.hadoop.hbase.master.MetricsMasterWrapper
-
Get the number of draining region servers
- getNumDrainingRegionServers() - Method in class org.apache.hadoop.hbase.master.MetricsMasterWrapperImpl
- getNumEntries() - Method in interface org.apache.hadoop.hbase.io.hfile.BlockIndexChunk
- getNumExceptions() - Method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
- getNumFilesCompacted() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
- getNumFilesCompacted() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
- getNumFlushesQueued() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
-
Returns the total number of flushes currently queued(being executed) for this region at point in time
- getNumFlushesQueued() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
- getNumGeneralCallsDropped() - Method in class org.apache.hadoop.hbase.ipc.DelegatingRpcScheduler
- getNumGeneralCallsDropped() - Method in class org.apache.hadoop.hbase.ipc.FifoRpcScheduler
- getNumGeneralCallsDropped() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapper
- getNumGeneralCallsDropped() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapperImpl
- getNumGeneralCallsDropped() - Method in class org.apache.hadoop.hbase.ipc.RpcExecutor
- getNumGeneralCallsDropped() - Method in class org.apache.hadoop.hbase.ipc.RpcScheduler
-
If CoDel-based RPC executors are used, retrieves the number of Calls that were dropped from general queue because RPC executor is under high load; returns 0 otherwise.
- getNumGeneralCallsDropped() - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
- getNumHFiles() - Method in class org.apache.hadoop.hbase.regionserver.HStore
- getNumHFiles() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Returns Number of HFiles in this store
- getNumHFiles(TableName, byte[]) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- getNumHFilesForRS(HRegionServer, TableName, byte[]) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- getNumKeysVerified() - Method in class org.apache.hadoop.hbase.util.MultiThreadedReader
- getNumLevels() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexWriter
-
Returns the number of levels in this block index.
- getNumLifoModeSwitches() - Method in class org.apache.hadoop.hbase.ipc.DelegatingRpcScheduler
- getNumLifoModeSwitches() - Method in class org.apache.hadoop.hbase.ipc.FifoRpcScheduler
- getNumLifoModeSwitches() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapper
- getNumLifoModeSwitches() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapperImpl
- getNumLifoModeSwitches() - Method in class org.apache.hadoop.hbase.ipc.RpcExecutor
- getNumLifoModeSwitches() - Method in class org.apache.hadoop.hbase.ipc.RpcScheduler
-
If CoDel-based RPC executors are used, retrieves the number of Calls that were picked from the tail of the queue (indicating adaptive LIFO mode, when in the period of overloade we serve last requests first); returns 0 otherwise.
- getNumLifoModeSwitches() - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
- getNumLiveRegionServers() - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.Returns Number of live region servers in the cluster currently.
- getNumLogFiles() - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
Returns the number of log files in use
- getNumLogFiles() - Method in class org.apache.hadoop.hbase.wal.AbstractWALProvider
- getNumLogFiles() - Method in interface org.apache.hadoop.hbase.wal.WALProvider
-
Get number of the log files this provider is managing
- getNumLogFiles0() - Method in class org.apache.hadoop.hbase.wal.AbstractFSWALProvider
-
iff the given WALFactory is using the DefaultWALProvider for meta and/or non-meta, count the number of files (rolled and active).
- getNumLogFiles0() - Method in class org.apache.hadoop.hbase.wal.AbstractWALProvider
- getNumLogFiles0() - Method in class org.apache.hadoop.hbase.wal.RegionGroupingProvider
- getNumMasters() - Method in class org.apache.hadoop.hbase.StartMiniClusterOption
-
Deprecated.
- getNumMasters() - Method in class org.apache.hadoop.hbase.testing.TestingHBaseClusterOption
- getNumMutationsWithoutWAL() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
- getNumMutationsWithoutWAL() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Number of mutations received with WAL explicitly turned off.
- getNumMutationsWithoutWAL() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Returns the number of mutations processed bypassing the WAL
- getNumObservers() - Method in class org.apache.hadoop.hbase.conf.ConfigurationManager
-
Returns the number of observers.
- getNumOfAppends() - Method in class org.apache.hadoop.hbase.regionserver.MiniBatchOperationInProgress
- getNumOfCells() - Method in class org.apache.hadoop.hbase.regionserver.VersionedSegmentsList
- getNumOfDeletes() - Method in class org.apache.hadoop.hbase.regionserver.MiniBatchOperationInProgress
- getNumOfIncrements() - Method in class org.apache.hadoop.hbase.regionserver.MiniBatchOperationInProgress
- getNumOfPuts() - Method in class org.apache.hadoop.hbase.regionserver.MiniBatchOperationInProgress
- getNumOfSegments() - Method in class org.apache.hadoop.hbase.regionserver.CompositeImmutableSegment
- getNumOfSegments() - Method in class org.apache.hadoop.hbase.regionserver.ImmutableSegment
- getNumOfSegments() - Method in class org.apache.hadoop.hbase.regionserver.VersionedSegmentsList
- getNumOnlineRegions() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
The number of online regions
- getNumOpenConnections() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapper
- getNumOpenConnections() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapperImpl
- getNumOpenConnections() - Method in class org.apache.hadoop.hbase.ipc.NettyRpcServer
- getNumOpenConnections() - Method in class org.apache.hadoop.hbase.ipc.RpcServer
-
The number of open RPC conections
- getNumOpenConnections() - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcServer
-
Deprecated.The number of open RPC conections
- getNumPositivesForTesting(int) - Method in class org.apache.hadoop.hbase.io.hfile.CompoundBloomFilter
- getNumQueriesForTesting(int) - Method in class org.apache.hadoop.hbase.io.hfile.CompoundBloomFilter
- getNumReadErrors() - Method in class org.apache.hadoop.hbase.util.MultiThreadedReader
- getNumReadFailures() - Method in class org.apache.hadoop.hbase.util.MultiThreadedReader
- getNumRecordsFailedPuts() - Method in interface org.apache.hadoop.hbase.namequeues.MetricsWALEventTrackerSource
- getNumRecordsFailedPuts() - Method in class org.apache.hadoop.hbase.namequeues.MetricsWALEventTrackerSourceImpl
- getNumReferenceFiles() - Method in class org.apache.hadoop.hbase.regionserver.HStore
- getNumReferenceFiles() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Returns Number of reference files on this region server
- getNumReferenceFiles() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
-
Returns Number of reference files under this region
- getNumReferenceFiles() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
- getNumReferenceFiles() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Returns Number of reference files in this store
- getNumReferenceFiles(String) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregate
-
Returns Number of reference files for this table
- getNumReferenceFiles(String) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImpl
- getNumRegions() - Method in class org.apache.hadoop.hbase.util.HbckTableInfo
- getNumRegions(String) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregate
-
Get the number of regions hosted on for this table
- getNumRegions(String) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImpl
- getNumRegionServers() - Method in interface org.apache.hadoop.hbase.master.MetricsMasterWrapper
-
Get the number of live region servers
- getNumRegionServers() - Method in class org.apache.hadoop.hbase.master.MetricsMasterWrapperImpl
- getNumRegionServers() - Method in class org.apache.hadoop.hbase.StartMiniClusterOption
-
Deprecated.
- getNumRegionServers() - Method in class org.apache.hadoop.hbase.testing.TestingHBaseClusterOption
- getNumRolledLogFiles() - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
Returns the number of rolled log files
- getNumRolledLogFiles(WAL) - Static method in class org.apache.hadoop.hbase.wal.AbstractFSWALProvider
-
returns the number of rolled WAL files.
- getNumRootEntries() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexWriter
-
Returns how many block index entries there are in the root level
- getNumSinks() - Method in class org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint
- getNumStoreFiles() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the number of store files hosted on this region server.
- getNumStoreFiles() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
-
Get the number of store files hosted on this region server.
- getNumStoreFiles() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
- getNumStoreFiles(String) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregate
-
Get the number of store files hosted for this table
- getNumStoreFiles(String) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImpl
- getNumStores() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the number of stores hosted on this region server.
- getNumStores() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
-
Get the number of stores hosted on this region server.
- getNumStores() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
- getNumStores() - Method in class org.apache.hadoop.hbase.regionserver.RegionServicesForStores
- getNumStores(String) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregate
-
Get the number of stores hosted on for this table
- getNumStores(String) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImpl
- getNumThreads(String) - Method in class org.apache.hadoop.hbase.util.LoadTestTool
- getNumUniqueKeys() - Method in class org.apache.hadoop.hbase.regionserver.CellSet
- getNumUniqueKeys() - Method in class org.apache.hadoop.hbase.regionserver.ImmutableSegment
- getNumUniqueKeysVerified() - Method in class org.apache.hadoop.hbase.util.MultiThreadedReader
- getNumWALFiles() - Method in class org.apache.hadoop.hbase.master.HMaster
- getNumWALFiles() - Method in interface org.apache.hadoop.hbase.master.MetricsMasterWrapper
-
Get the number of master WAL files.
- getNumWALFiles() - Method in class org.apache.hadoop.hbase.master.MetricsMasterWrapperImpl
- getNumWALFiles() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the number of WAL files of this region server.
- getNumWALSlowAppend() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the number of WAL files with slow appends for this region server.
- getNumWriteFailures() - Method in class org.apache.hadoop.hbase.util.MultiThreadedWriterBase
- getNumZkServers() - Method in class org.apache.hadoop.hbase.StartMiniClusterOption
-
Deprecated.
- getNumZkServers() - Method in class org.apache.hadoop.hbase.testing.TestingHBaseClusterOption
- getObjectFromMessage(byte[]) - Method in interface org.apache.hadoop.hbase.rest.ProtobufMessageHandler
-
Initialize the model from a protobuf representation.
- getObjectFromMessage(InputStream) - Method in interface org.apache.hadoop.hbase.rest.ProtobufMessageHandler
-
Initialize the model from a protobuf representation.
- getObjectFromMessage(CodedInputStream) - Method in interface org.apache.hadoop.hbase.rest.ProtobufMessageHandler
- getObservedSnapshotSizes(Connection) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
Fetches any persisted HBase snapshot sizes stored in the quota table.
- getOffHeapMemStoreLimit() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the limit size of the off heap memstore.
- getOffHeapMemStoreSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the size of the off heap memstore on this region server.
- getOffHeapSize() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreSize
- getOffHeapSize() - Method in interface org.apache.hadoop.hbase.regionserver.MemStoreSizing
- getOffHeapSize() - Method in class org.apache.hadoop.hbase.regionserver.Segment
- getOffPeakHours() - Method in class org.apache.hadoop.hbase.regionserver.HStore
- getOffset() - Method in class org.apache.hadoop.hbase.ByteBufferKeyValue
- getOffset() - Method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
- getOffset() - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheKey
- getOffset() - Method in interface org.apache.hadoop.hbase.io.hfile.CachedBlock
- getOffset() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
Cannot be
HFileBlock.UNSET
. - getOffset() - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
-
Return the offset into the buffer.
- getOffset() - Method in class org.apache.hadoop.hbase.KeyValue
-
Returns Offset into
KeyValue.getBuffer()
at which this KeyValue starts. - getOffset() - Method in class org.apache.hadoop.hbase.replication.ReplicationGroupOffset
-
A negative value means this file has already been fully replicated out
- getOffset() - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
- getOffset() - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
The offset, the index into the underlying byte[] at which this range begins.
- getOffset() - Method in class org.apache.hadoop.hbase.util.Bytes
-
Return the offset into the buffer.
- getOffsets() - Method in class org.apache.hadoop.hbase.replication.ReplicationQueueData
- getOffsets(ReplicationQueueId) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueueStorage
-
Get the current offset of all the WAL groups for a queue
- getOffsets(ReplicationQueueId) - Method in class org.apache.hadoop.hbase.replication.TableReplicationQueueStorage
- getOldestHfileTs(boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
- getOldestHfileTs(boolean) - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
This can be used to determine the last time all files of this region were major compacted.
- getOldestSeqIdOfStore(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
- getOldPath() - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
- getOldWALsDirSize() - Method in class org.apache.hadoop.hbase.master.MasterWalManager
- getOldWALsDirSize() - Method in interface org.apache.hadoop.hbase.master.MetricsMasterWrapper
-
Get the size of old WALs directory in bytes.
- getOldWALsDirSize() - Method in class org.apache.hadoop.hbase.master.MetricsMasterWrapperImpl
- getOnDiskDataSize(int) - Method in interface org.apache.hadoop.hbase.io.hfile.BlockIndexChunk
- getOnDiskSizeWithHeader() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
Returns the on-disk size of header + data part + checksum.
- getOneArgStaticMethodAsFunction(Class<?>, String, Class<I>, Class<R>) - Static method in class org.apache.hadoop.hbase.util.ReflectionUtils
-
Creates a Function which can be called to performantly execute a reflected static method.
- getOneMinuteRate() - Method in interface org.apache.hadoop.hbase.metrics.Meter
-
Returns the one-minute exponentially-weighted moving average rate at which events have occurred since the meter was created.
- getOneRandomServer(String, Set<ServerName>) - Method in class org.apache.hadoop.hbase.favored.FavoredNodeAssignmentHelper
-
Gets a random server from the specified rack and skips anything specified.
- getOnHeapCacheSize(Configuration) - Static method in class org.apache.hadoop.hbase.io.util.MemorySizeUtil
- getOnheapGlobalMemStoreSize(Configuration) - Static method in class org.apache.hadoop.hbase.io.util.MemorySizeUtil
-
Returns the onheap global memstore limit based on the config 'hbase.regionserver.global.memstore.size'.
- getOnHeapMemStoreLimit() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the limit size of the on heap memstore.
- getOnHeapMemStoreSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the size of the on heap memstore on this region server.
- getOnlineEntries() - Method in class org.apache.hadoop.hbase.util.HbckRegionInfo
- getOnlineRegion(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
- getOnlineRegion(AdminProtos.GetOnlineRegionRequest) - Method in class org.apache.hadoop.hbase.client.AsyncRegionServerAdmin
- getOnlineRegion(RpcController, AdminProtos.GetOnlineRegionRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- getOnlineRegion(RpcController, AdminProtos.GetOnlineRegionRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
- getOnlineRegions() - Method in interface org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment
-
Returns Interface to Map of regions online on this RegionServer
RegionCoprocessorEnvironment.getServerName()
}. - getOnlineRegions() - Method in interface org.apache.hadoop.hbase.coprocessor.RegionServerCoprocessorEnvironment
-
Returns Interface to Map of regions online on this RegionServer
RegionServerCoprocessorEnvironment.getServerName()
}. - getOnlineRegions() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
- getOnlineRegions(AdminProtos.AdminService.BlockingInterface) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
A helper to get the all the online regions on a region server using admin protocol.
- getOnlineRegions(RpcController, AdminProtos.AdminService.BlockingInterface) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
A helper to get the all the online regions on a region server using admin protocol.
- getOnlineRegionsInterface(ServerName) - Method in interface org.apache.hadoop.hbase.testing.TestingHBaseCluster
-
Get the server side
OnlineRegions
interface for the specific region server. - getOnlineRegionsLocalContext() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
For tests, web ui and metrics.
- getOnlineServers() - Method in class org.apache.hadoop.hbase.master.ServerManager
-
Returns Read-only map of servers to serverinfo
- getOnlineServersList() - Method in class org.apache.hadoop.hbase.master.ServerManager
-
Returns A copy of the internal list of online servers.
- getOnlineServersListWithPredicator(List<ServerName>, Predicate<ServerMetrics>) - Method in class org.apache.hadoop.hbase.master.ServerManager
- getOnlineTables() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Gets the online tables in this RS.
- getOpenFileDescriptorCount() - Method in class org.apache.hadoop.hbase.util.JVM
-
Get the number of opened filed descriptor for the runtime jvm.
- getOpenMetrics() - Method in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
-
Returns
OperationMetrics
containing common metrics for open region request - getOpenMetrics() - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManagerSourceImpl
- getOpenProcId() - Method in class org.apache.hadoop.hbase.regionserver.RegionServerServices.PostOpenDeployContext
- getOpenProcMetrics() - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManager
-
Returns Set of common metrics for OpenRegionProcedure
- getOpenRegions() - Method in class org.apache.hadoop.hbase.client.RegionStatesCount
- getOpenSeqNum() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Returns the latest sequence number that was read from storage when this region was opened
- getOpenSeqNum() - Method in class org.apache.hadoop.hbase.regionserver.RegionServerServices.RegionStateTransitionContext
- getOperation(int) - Method in class org.apache.hadoop.hbase.regionserver.MiniBatchOperationInProgress
-
Returns The operation(Mutation) at the specified position.
- getOperationId() - Method in interface org.apache.hadoop.hbase.regionserver.RegionScanner
- getOperationsFromCoprocessors(int) - Method in class org.apache.hadoop.hbase.regionserver.MiniBatchOperationInProgress
- getOperationStatus(int) - Method in class org.apache.hadoop.hbase.regionserver.MiniBatchOperationInProgress
-
Returns Gets the status code for the operation(Mutation) at the specified position.
- getOperationStatusCode() - Method in class org.apache.hadoop.hbase.regionserver.OperationStatus
- getOperationTimeout() - Method in interface org.apache.hadoop.hbase.client.Admin
-
Return the operation timeout for a rpc call.
- getOperationTimeout() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
- getOperationTimeout() - Method in class org.apache.hadoop.hbase.client.ConnectionConfiguration
- getOperationTimeout(TimeUnit) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
Get timeout of each operation in Table instance.
- getOperationTimeout(TimeUnit) - Method in interface org.apache.hadoop.hbase.client.Table
-
Get timeout of each operation in Table instance.
- getOperator() - Method in class org.apache.hadoop.hbase.filter.BitComparator
-
Returns the bitwise operator
- getOperator() - Method in class org.apache.hadoop.hbase.filter.FilterList
-
Get the operator.
- getOPsShipped() - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSource
- getOption() - Method in enum class org.apache.hadoop.hbase.thrift.ImplType
- getOptionAsDouble(CommandLine, String, double) - Method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
- getOptionAsInt(CommandLine, String, int) - Method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
- getOptionAsInt(CommandLine, String, int, int) - Method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
- getOptionAsLong(CommandLine, String, int) - Method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
- getOptionAsLong(CommandLine, String, int, int) - Method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
- getOptions() - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupMajorCompactionTTL
- getOrCreate(K, PoolMap.PoolResourceSupplier<V>) - Method in class org.apache.hadoop.hbase.util.PoolMap
- getOrCreate(PoolMap.PoolResourceSupplier<R>) - Method in interface org.apache.hadoop.hbase.util.PoolMap.Pool
- getOrCreateMetricsClient(String) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsUserSource
-
Create a instance of ClientMetrics if not present otherwise return the previous one
- getOrCreateMetricsClient(String) - Method in class org.apache.hadoop.hbase.regionserver.MetricsUserSourceImpl
- getOrCreateMetricsUser(String) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsUserAggregateSource
-
Returns a MetricsUserSource if already exists, or creates and registers one for this user
- getOrCreateMetricsUser(String) - Method in class org.apache.hadoop.hbase.regionserver.MetricsUserAggregateSourceImpl
- getOrCreateTableSource(String, MetricsTableWrapperAggregate) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableAggregateSource
-
Returns MetricsTableSource registered for the table.
- getOrCreateTableSource(String, MetricsTableWrapperAggregate) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableAggregateSourceImpl
- getOrder() - Method in interface org.apache.hadoop.hbase.types.DataType
-
Retrieve the sort
Order
imposed by this data type, or null when natural ordering is not preserved. - getOrder() - Method in class org.apache.hadoop.hbase.types.FixedLengthWrapper
- getOrder() - Method in class org.apache.hadoop.hbase.types.OrderedBytesBase
- getOrder() - Method in class org.apache.hadoop.hbase.types.PBType
- getOrder() - Method in class org.apache.hadoop.hbase.types.RawByte
- getOrder() - Method in class org.apache.hadoop.hbase.types.RawBytes
- getOrder() - Method in class org.apache.hadoop.hbase.types.RawDouble
- getOrder() - Method in class org.apache.hadoop.hbase.types.RawFloat
- getOrder() - Method in class org.apache.hadoop.hbase.types.RawInteger
- getOrder() - Method in class org.apache.hadoop.hbase.types.RawLong
- getOrder() - Method in class org.apache.hadoop.hbase.types.RawShort
- getOrder() - Method in class org.apache.hadoop.hbase.types.RawString
- getOrder() - Method in class org.apache.hadoop.hbase.types.Struct
- getOrder() - Method in class org.apache.hadoop.hbase.types.TerminatedWrapper
- getOrder() - Method in class org.apache.hadoop.hbase.types.Union2
- getOrder() - Method in class org.apache.hadoop.hbase.types.Union3
- getOrder() - Method in class org.apache.hadoop.hbase.types.Union4
- getOrderOfSize() - Method in enum class org.apache.hadoop.hbase.Size.Unit
- getOriginalIndex() - Method in class org.apache.hadoop.hbase.client.Action
- getOriginatingClusterId() - Method in interface org.apache.hadoop.hbase.wal.WALKey
- getOriginatingClusterId() - Method in class org.apache.hadoop.hbase.wal.WALKeyImpl
- getOriginPath() - Method in class org.apache.hadoop.hbase.io.HFileLink
-
Returns the origin path of the hfile.
- getOrigLogSeqNum() - Method in interface org.apache.hadoop.hbase.wal.WALKey
-
Return a positive long if current WALKeyImpl is created from a replay edit; a replay edit is an edit that came in when replaying WALs of a crashed server.
- getOrigLogSeqNum() - Method in class org.apache.hadoop.hbase.wal.WALKeyImpl
-
Return a positive long if current WALKeyImpl is created from a replay edit; a replay edit is an edit that came in when replaying WALs of a crashed server.
- getOtherRegionServer(HRegionServer) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Find any other region server which is different from the one identified by parameter
- getOuputStream() - Method in class org.apache.hadoop.hbase.codec.BaseEncoder
- getOutput() - Method in class org.apache.hadoop.hbase.regionserver.wal.AsyncProtobufLogWriter
- getOutputCommitter(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableOutputFormat
- getOutputCommitter(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputFormat
-
Returns the output committer.
- getOutputCounts() - Method in class org.apache.hadoop.hbase.wal.BoundedRecoveredHFilesOutputSink
- getOutputStream() - Method in class org.apache.hadoop.hbase.security.HBaseSaslRpcClient
-
Get a SASL wrapped OutputStream.
- getOutputStreamForCellEncoder() - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractProtobufLogWriter
- getOutputStreamForCellEncoder() - Method in class org.apache.hadoop.hbase.regionserver.wal.AsyncProtobufLogWriter
- getOutputStreamForCellEncoder() - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogWriter
- getOwner() - Method in class org.apache.hadoop.hbase.client.SnapshotDescription
- getPageEndPosition() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.Paging
- getPageSize() - Method in class org.apache.hadoop.hbase.filter.PageFilter
- getPageSize() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenView
- getPageStartPosition() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.Paging
- getParam() - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord
- getParam() - Method in interface org.apache.hadoop.hbase.ipc.RpcCall
-
Returns The call parameter message.
- getParam() - Method in class org.apache.hadoop.hbase.ipc.ServerCall
- getParam() - Method in class org.apache.hadoop.hbase.namequeues.RpcLogDetails
- getParameter(String) - Method in class org.apache.hadoop.hbase.http.HttpServer.QuotingInputFilter.RequestQuoter
-
Unquote the name and quote the value.
- getParameterMap() - Method in class org.apache.hadoop.hbase.http.HttpServer.QuotingInputFilter.RequestQuoter
- getParameterNames() - Method in class org.apache.hadoop.hbase.http.HttpServer.QuotingInputFilter.RequestQuoter
-
Return the set of parameter names, quoting each name.
- getParameterValues(String) - Method in class org.apache.hadoop.hbase.http.HttpServer.QuotingInputFilter.RequestQuoter
- getParams() - Method in class org.apache.hadoop.hbase.client.SlowLogParams
- getParent(String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Returns the full path of the immediate parent of the specified node.
- getParentRegionNames() - Method in class org.apache.hadoop.hbase.replication.ReplicationBarrierFamilyFormat.ReplicationBarrierResult
- getParentsBytes(List<RegionInfo>) - Static method in class org.apache.hadoop.hbase.replication.ReplicationBarrierFamilyFormat
- getParentToChildrenPairMap() - Method in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper.RestoreMetaChanges
-
Returns the map of parent-children_pair.
- getPartition(ImmutableBytesWritable, V2, int) - Method in class org.apache.hadoop.hbase.mapred.HRegionPartitioner
- getPartition(ImmutableBytesWritable, VALUE, int) - Method in class org.apache.hadoop.hbase.mapreduce.HRegionPartitioner
-
Gets the partition number for a given key (hence record) given the total number of partitions i.e.
- getPartition(ImmutableBytesWritable, VALUE, int) - Method in class org.apache.hadoop.hbase.mapreduce.SimpleTotalOrderPartitioner
- getPartition(Import.CellWritableComparable, Cell, int) - Method in class org.apache.hadoop.hbase.mapreduce.Import.CellWritableComparablePartitioner
- getPassword(String) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
- getPassword(Configuration, String, String) - Static method in class org.apache.hadoop.hbase.HBaseConfiguration
-
Get the password from the Configuration instance using the getPassword method if it exists.
- getPath() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
- getPath() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Writer
-
Returns the path to this
HFile
- getPath() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
- getPath() - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterImpl
-
Returns Path or null if we were passed a stream rather than a Path.
- getPath() - Method in class org.apache.hadoop.hbase.regionserver.HMobStore
-
Gets the mob file path.
- getPath() - Method in class org.apache.hadoop.hbase.regionserver.HStoreFile
- getPath() - Method in interface org.apache.hadoop.hbase.regionserver.StoreFile
-
Returns Path or null if this StoreFile was made with a Stream.
- getPath() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
Returns The
Path
of the file - getPath() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileWriter
- getPath() - Method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp
-
Returns path to znode where the ZKOp will occur
- getPath(Path) - Static method in class org.apache.hadoop.hbase.util.CommonFSUtils
-
Return the 'path' component of a Path.
- getPaths() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileWriter
- getPattern(String, Pattern) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
- getPauseNsFromException(Throwable, int, long) - Method in class org.apache.hadoop.hbase.client.backoff.HBaseServerExceptionPauseManager
-
Returns the nanos, if any, for which the client should wait
- getPauseTime(long, int) - Static method in class org.apache.hadoop.hbase.client.ConnectionUtils
-
Calculate pause time.
- getPeer(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeers
-
Returns the ReplicationPeerImpl for the specified cached peer.
- getPeerActionListener() - Method in class org.apache.hadoop.hbase.wal.AbstractWALProvider
- getPeerActionListener() - Method in interface org.apache.hadoop.hbase.wal.WALProvider
- getPeerBandwidth() - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeer
-
Get the per node bandwidth upper limit for this peer
- getPeerBandwidth() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerImpl
- getPeerCache() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeers
- getPeerClusterConfiguration(Configuration, ReplicationPeerConfig) - Static method in class org.apache.hadoop.hbase.client.replication.ReplicationPeerConfigUtil
-
Returns the configuration needed to talk to the remote slave cluster.
- getPeerConfig() - Method in class org.apache.hadoop.hbase.replication.ReplicationEndpoint.Context
- getPeerConfig() - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeer
-
Get the peer config object
- getPeerConfig() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerDescription
- getPeerConfig() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerImpl
- getPeerConfig(String) - Method in class org.apache.hadoop.hbase.replication.FSReplicationPeerStorage
- getPeerConfig(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeerStorage
-
Get the peer config of a replication peer.
- getPeerConfig(String) - Method in class org.apache.hadoop.hbase.replication.ZKReplicationPeerStorage
- getPeerData() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
- getPeerId() - Method in class org.apache.hadoop.hbase.replication.ReplicationEndpoint.Context
- getPeerId() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerDescription
- getPeerId() - Method in class org.apache.hadoop.hbase.replication.ReplicationQueueId
- getPeerId() - Method in class org.apache.hadoop.hbase.replication.ReplicationQueueInfo
- getPeerId() - Method in class org.apache.hadoop.hbase.replication.ZKReplicationQueueStorageForMigration.ZkLastPushedSeqId
- getPeerId(String) - Static method in class org.apache.hadoop.hbase.replication.ReplicationQueueId
- getPeerID() - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSource
- getPeerNewSyncReplicationState(String) - Method in class org.apache.hadoop.hbase.replication.FSReplicationPeerStorage
- getPeerNewSyncReplicationState(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeerStorage
-
Get the new sync replication state.
- getPeerNewSyncReplicationState(String) - Method in class org.apache.hadoop.hbase.replication.ZKReplicationPeerStorage
- getPeerNode(String) - Method in class org.apache.hadoop.hbase.replication.ZKReplicationPeerStorage
- getPeerProcedureHandler() - Method in interface org.apache.hadoop.hbase.regionserver.ReplicationSourceService
-
Returns a Handler to handle peer procedures.
- getPeerRemoteWALDir(String, String) - Static method in class org.apache.hadoop.hbase.replication.ReplicationUtils
- getPeerRemoteWALDir(Path, String) - Static method in class org.apache.hadoop.hbase.replication.ReplicationUtils
- getPeerReplayWALDir(Path, String) - Static method in class org.apache.hadoop.hbase.replication.ReplicationUtils
- getPeerSnapshotWALDir(String, String) - Static method in class org.apache.hadoop.hbase.replication.ReplicationUtils
- getPeerSnapshotWALDir(Path, String) - Static method in class org.apache.hadoop.hbase.replication.ReplicationUtils
- getPeerState() - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeer
-
Returns the state of the peer by reading local cache.
- getPeerState() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerImpl
- getPeerStateNode(String) - Method in class org.apache.hadoop.hbase.replication.ZKReplicationPeerStorage
- getPeerStorage() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeers
- getPeerSyncReplicationState(String) - Method in class org.apache.hadoop.hbase.replication.FSReplicationPeerStorage
- getPeerSyncReplicationState(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeerStorage
-
Get the sync replication state.
- getPeerSyncReplicationState(String) - Method in class org.apache.hadoop.hbase.replication.ZKReplicationPeerStorage
- getPeerUUID() - Method in class org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint
- getPeerUUID() - Method in interface org.apache.hadoop.hbase.replication.ReplicationEndpoint
-
Returns a UUID of the provided peer id.
- getPeerUUID() - Method in class org.apache.hadoop.hbase.replication.VerifyWALEntriesReplicationEndpoint
- getPercentFileLocal() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the percent of HFiles' that are local.
- getPercentFileLocalSecondaryRegions() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the percent of HFiles' that are local for secondary region replicas.
- getPeriod() - Method in class org.apache.hadoop.hbase.ScheduledChore
-
Returns period to execute chore in getTimeUnit() units
- getPeriod() - Method in class org.apache.hadoop.hbase.util.Sleeper
-
Returns the sleep period in milliseconds
- getPeriodicalFlushTimeout(TimeUnit) - Method in interface org.apache.hadoop.hbase.client.AsyncBufferedMutator
-
Returns the periodical flush interval, 0 means disabled.
- getPhase() - Method in class org.apache.hadoop.hbase.backup.BackupInfo
- getPid() - Static method in class org.apache.hadoop.hbase.util.ProcessUtils
- getPipeline() - Method in interface org.apache.hadoop.hbase.io.asyncfs.AsyncFSOutput
-
Return current pipeline.
- getPipeline() - Method in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutput
- getPipeline() - Method in class org.apache.hadoop.hbase.io.asyncfs.WrapperAsyncFSOutput
- getPipelineSize() - Method in class org.apache.hadoop.hbase.regionserver.CompactionPipeline
- getPolicies() - Method in class org.apache.hadoop.hbase.quotas.ActivePolicyEnforcement
-
Returns an unmodifiable version of the active
SpaceViolationPolicyEnforcement
s. - getPolicy() - Method in class org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot.SpaceQuotaStatus
-
Returns the violation policy, which may be null.
- getPolicy() - Method in interface org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshotView.SpaceQuotaStatusView
-
Returns the violation policy, which may not be presented.
- getPolicyEnforcement(Region) - Method in class org.apache.hadoop.hbase.quotas.ActivePolicyEnforcement
-
Returns the proper
SpaceViolationPolicyEnforcement
implementation for the given table. - getPolicyEnforcement(TableName) - Method in class org.apache.hadoop.hbase.quotas.ActivePolicyEnforcement
-
Returns the proper
SpaceViolationPolicyEnforcement
implementation for the given table. - getPolicyName() - Method in class org.apache.hadoop.hbase.quotas.policies.DefaultViolationPolicyEnforcement
- getPolicyName() - Method in class org.apache.hadoop.hbase.quotas.policies.DisableTableViolationPolicyEnforcement
- getPolicyName() - Method in class org.apache.hadoop.hbase.quotas.policies.MissingSnapshotViolationPolicyEnforcement
- getPolicyName() - Method in class org.apache.hadoop.hbase.quotas.policies.NoInsertsViolationPolicyEnforcement
- getPolicyName() - Method in class org.apache.hadoop.hbase.quotas.policies.NoWritesCompactionsViolationPolicyEnforcement
- getPolicyName() - Method in class org.apache.hadoop.hbase.quotas.policies.NoWritesViolationPolicyEnforcement
- getPolicyName() - Method in interface org.apache.hadoop.hbase.quotas.SpaceViolationPolicyEnforcement
-
Returns a logical name for the
SpaceViolationPolicy
that this enforcement is for. - getPool() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
-
Deprecated.Since 3.0.0-alpha-2, will be removed in 4.0.0. You can not set it anymore. BufferedMutator will use Connection's ExecutorService.
- getPoolAllocationBytes() - Method in class org.apache.hadoop.hbase.io.ByteBuffAllocator
- getPoolCompletedTaskCount() - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
- getPoolCompletedTaskCount() - Method in interface org.apache.hadoop.hbase.thrift.IncrementCoalescerMBean
- getPoolLargestPoolSize() - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
- getPoolLargestPoolSize() - Method in interface org.apache.hadoop.hbase.thrift.IncrementCoalescerMBean
- getPoolTaskCount() - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
- getPoolTaskCount() - Method in interface org.apache.hadoop.hbase.thrift.IncrementCoalescerMBean
- getPort() - Method in exception org.apache.hadoop.hbase.exceptions.RegionMovedException
- getPort() - Method in class org.apache.hadoop.hbase.HRegionLocation
- getPort() - Method in class org.apache.hadoop.hbase.http.HttpServer
-
Deprecated.Since 0.99.0
- getPort() - Method in class org.apache.hadoop.hbase.http.InfoServer
-
Deprecated.Since 0.99.0
- getPort() - Method in exception org.apache.hadoop.hbase.ipc.RemoteWithExtrasException
-
Returns -1 if not set
- getPort() - Method in class org.apache.hadoop.hbase.net.Address
- getPort() - Method in class org.apache.hadoop.hbase.rest.RESTServer
- getPort() - Method in class org.apache.hadoop.hbase.ServerName
- getPortConfigName() - Method in class org.apache.hadoop.hbase.HBaseRpcServicesBase
- getPortConfigName() - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- getPortConfigName() - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
- getPos() - Method in class org.apache.hadoop.hbase.io.FileLink.FileLinkInputStream
- getPos() - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterImpl
- getPos() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
- getPos() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
- getPos() - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.RecordReader
- getPos() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileWriter
- getPosition() - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractProtobufWALReader
- getPosition() - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
- getPosition() - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
The current
position
marker. - getPosition() - Method in interface org.apache.hadoop.hbase.wal.WALStreamReader
-
Get the current reading position.
- getPosition() - Method in interface org.apache.hadoop.hbase.wal.WALTailingReader
-
Get the current reading position.
- getPositionQuietly() - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractProtobufWALReader
- getPreadScanner(boolean, long, long, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HStoreFile
-
Get a scanner which uses pread.
- getPreallocatedEventCount() - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
- getPrefetchDelay() - Static method in class org.apache.hadoop.hbase.io.hfile.PrefetchExecutor
- getPrefetchDelay() - Method in class org.apache.hadoop.hbase.regionserver.PrefetchExecutorNotifier
- getPrefix() - Method in class org.apache.hadoop.hbase.filter.ColumnPrefixFilter
- getPrefix() - Method in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
- getPrefix() - Method in class org.apache.hadoop.hbase.filter.PrefixFilter
- getPrefixLength() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileReader
- getPrettyHistogramReport(Histogram) - Static method in class org.apache.hadoop.hbase.util.YammerHistogramUtils
-
Returns pretty summary of
hist
. - getPrevCell() - Method in class org.apache.hadoop.hbase.io.hfile.CompoundBloomFilterWriter
- getPrevCell() - Method in interface org.apache.hadoop.hbase.util.BloomFilterWriter
-
Returns the previous cell written by this writer
- getPrimaryCallTimeoutMicroSecond() - Method in class org.apache.hadoop.hbase.client.ConnectionConfiguration
- getPrimaryEvictedCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
- getPrimaryEvictedCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
- getPrimaryHitCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
- getPrimaryHitCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
- getPrimaryHRIForDeployedReplica() - Method in class org.apache.hadoop.hbase.util.HbckRegionInfo
- getPrimaryMissCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
- getPrimaryMissCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
- getPrimaryToRegionInfoMap() - Method in class org.apache.hadoop.hbase.master.SnapshotOfRegionAssignmentFromMeta
- getPrincipalWithoutRealm(String) - Static method in class org.apache.hadoop.hbase.security.SecurityUtil
-
Get the user name from a principal
- getPriority() - Method in class org.apache.hadoop.hbase.client.Action
- getPriority() - Method in interface org.apache.hadoop.hbase.client.CoprocessorDescriptor
-
Returns The order to execute this coprocessor
- getPriority() - Method in class org.apache.hadoop.hbase.client.ImmutableScan
- getPriority() - Method in class org.apache.hadoop.hbase.client.OperationWithAttributes
- getPriority() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
- getPriority() - Method in class org.apache.hadoop.hbase.coprocessor.BaseEnvironment
- getPriority() - Method in interface org.apache.hadoop.hbase.CoprocessorEnvironment
-
Returns the priority assigned to the loaded coprocessor
- getPriority() - Method in class org.apache.hadoop.hbase.io.hfile.LruCachedBlock
- getPriority() - Method in class org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
- getPriority() - Method in interface org.apache.hadoop.hbase.ipc.HBaseRpcController
-
Returns The priority of this request
- getPriority() - Method in class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
- getPriority() - Method in interface org.apache.hadoop.hbase.ipc.RpcCall
-
Returns The Priority of this call.
- getPriority() - Method in class org.apache.hadoop.hbase.ipc.ServerCall
- getPriority(RPCProtos.RequestHeader, Message, User) - Method in class org.apache.hadoop.hbase.HBaseRpcServicesBase
- getPriority(RPCProtos.RequestHeader, Message, User) - Method in class org.apache.hadoop.hbase.ipc.AnnotationReadingPriorityFunction
-
Returns a 'priority' based on the request type.
- getPriority(RPCProtos.RequestHeader, Message, User) - Method in interface org.apache.hadoop.hbase.ipc.PriorityFunction
-
Returns the 'priority type' of the specified request.
- getPriorityQueueLength() - Method in class org.apache.hadoop.hbase.ipc.DelegatingRpcScheduler
- getPriorityQueueLength() - Method in class org.apache.hadoop.hbase.ipc.FifoRpcScheduler
- getPriorityQueueLength() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapper
- getPriorityQueueLength() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapperImpl
- getPriorityQueueLength() - Method in class org.apache.hadoop.hbase.ipc.RpcScheduler
-
Retrieves length of the priority queue for metrics.
- getPriorityQueueLength() - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
- getProcedureResult(RpcController, MasterProtos.GetProcedureResultRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- getProcedures() - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get procedures.
- getProcedures() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
List procedures
- getProcedures() - Method in class org.apache.hadoop.hbase.master.HMaster
- getProcedures() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Get procedures
- getProcedures(RpcController, MasterProtos.GetProceduresRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- getProcedureStore() - Method in class org.apache.hadoop.hbase.master.HMaster
- getProcessingTime() - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord
- getProcessName() - Method in class org.apache.hadoop.hbase.HBaseServerBase
- getProcessName() - Method in class org.apache.hadoop.hbase.master.HMaster
- getProcessName() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
- getProcessPID() - Static method in class org.apache.hadoop.hbase.util.JSONMetricUtil
- getProcIds() - Method in class org.apache.hadoop.hbase.regionserver.RegionServerServices.RegionStateTransitionContext
- getProgress() - Method in class org.apache.hadoop.hbase.backup.BackupInfo
-
Get current progress
- getProgress() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
- getProgress() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
- getProgress() - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReader
-
The current progress of the record reader through its data.
- getProgress() - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReaderImpl
-
The current progress of the record reader through its data.
- getProgress() - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.RecordReader
- getPromotedValueFromProto(R) - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
-
This method gets the promoted type from the proto message
- getProperties() - Method in interface org.apache.hadoop.hbase.client.CoprocessorDescriptor
-
Returns Arbitrary key-value parameter pairs passed into the coprocessor.
- getPropertySources(String) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
- getPropertyValue() - Method in enum class org.apache.hadoop.hbase.io.crypto.tls.KeyStoreFileType
-
The property string that specifies that a key store or trust store should use this store file type.
- getProtobuf(UriInfo, String) - Method in class org.apache.hadoop.hbase.rest.TableScanResource
- getProtocol() - Method in exception org.apache.hadoop.hbase.exceptions.UnknownProtocolException
- getProtocolFactory() - Method in class org.apache.hadoop.hbase.thrift.ThriftServer
- getProtoForCellType(T) - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
-
This method gets the PB message corresponding to the cell type
- getProtoForPromotedType(S) - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
-
This method gets the PB message corresponding to the promoted type
- getProtoViolationPolicy(SpaceViolationPolicy) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
- getProvider() - Method in class org.apache.hadoop.hbase.io.crypto.Cipher
-
Return the provider for this Cipher
- getProxyuserConfiguration(FilterConfig) - Method in class org.apache.hadoop.hbase.http.ProxyUserAuthenticationFilter
- getPushDownFilters() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenModel
- getPutTracker() - Method in class org.apache.hadoop.hbase.client.MetricsConnection
-
putTracker metric
- getQop(String) - Static method in class org.apache.hadoop.hbase.security.SaslUtil
-
Returns
SaslUtil.QualityOfProtection
corresponding to the givenstringQop
value. - getQualifiedMobRootDir(Configuration) - Static method in class org.apache.hadoop.hbase.mob.MobUtils
-
Gets the qualified root dir of the mob files.
- getQualifiedPath() - Method in class org.apache.hadoop.hbase.regionserver.HStoreFile
- getQualifiedPath() - Method in interface org.apache.hadoop.hbase.regionserver.StoreFile
-
Returns Returns the qualified path of this StoreFile
- getQualifiedStagingDir(Configuration) - Static method in class org.apache.hadoop.hbase.mapreduce.JobUtil
-
Initializes the staging directory and returns the qualified path.
- getQualifier() - Method in class org.apache.hadoop.hbase.client.CheckAndMutate
-
Returns the qualifier to check
- getQualifier() - Method in class org.apache.hadoop.hbase.filter.ColumnValueFilter
-
Returns the qualifier
- getQualifier() - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
-
Returns the column qualifier
- getQualifier() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
Returns the qualifier
- getQualifier() - Method in class org.apache.hadoop.hbase.TableName
- getQualifier(int) - Method in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
- getQualifierArray() - Method in class org.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValue
- getQualifierArray() - Method in class org.apache.hadoop.hbase.ByteBufferKeyValue
- getQualifierArray() - Method in interface org.apache.hadoop.hbase.Cell
-
Contiguous raw bytes that may start at any index in the containing array.
- getQualifierArray() - Method in class org.apache.hadoop.hbase.IndividualBytesFieldCell
- getQualifierArray() - Method in class org.apache.hadoop.hbase.KeyValue
-
Returns the backing array of the entire KeyValue (all KeyValue fields are in a single array)
- getQualifierArray() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
- getQualifierArray() - Method in class org.apache.hadoop.hbase.util.MapReduceExtendedCell
- getQualifierAsString() - Method in class org.apache.hadoop.hbase.TableName
- getQualifierByte(Cell, int) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
- getQualifierByteBuffer() - Method in class org.apache.hadoop.hbase.ByteBufferExtendedCell
-
Returns The
ByteBuffer
containing the column qualifier bytes. - getQualifierByteBuffer() - Method in class org.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValue
- getQualifierByteBuffer() - Method in class org.apache.hadoop.hbase.ByteBufferKeyValue
- getQualifierByteBuffer() - Method in class org.apache.hadoop.hbase.util.MapReduceExtendedCell
- getQualifierLength() - Method in class org.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValue
- getQualifierLength() - Method in class org.apache.hadoop.hbase.ByteBufferKeyValue
- getQualifierLength() - Method in interface org.apache.hadoop.hbase.Cell
-
Returns Number of qualifier bytes.
- getQualifierLength() - Method in class org.apache.hadoop.hbase.IndividualBytesFieldCell
- getQualifierLength() - Method in class org.apache.hadoop.hbase.KeyValue
-
Returns Qualifier length
- getQualifierLength() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
- getQualifierLength() - Method in class org.apache.hadoop.hbase.util.MapReduceExtendedCell
- getQualifierOffset() - Method in class org.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValue
- getQualifierOffset() - Method in class org.apache.hadoop.hbase.ByteBufferKeyValue
- getQualifierOffset() - Method in interface org.apache.hadoop.hbase.Cell
-
Returns Array index of first qualifier byte
- getQualifierOffset() - Method in class org.apache.hadoop.hbase.IndividualBytesFieldCell
- getQualifierOffset() - Method in class org.apache.hadoop.hbase.KeyValue
-
Returns Qualifier offset
- getQualifierOffset() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
- getQualifierOffset() - Method in class org.apache.hadoop.hbase.util.MapReduceExtendedCell
- getQualifierPosition() - Method in class org.apache.hadoop.hbase.ByteBufferExtendedCell
-
Returns Position in the
ByteBuffer
where column qualifier bytes start - getQualifierPosition() - Method in class org.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValue
- getQualifierPosition() - Method in class org.apache.hadoop.hbase.ByteBufferKeyValue
- getQualifierPosition() - Method in class org.apache.hadoop.hbase.util.MapReduceExtendedCell
- getQualifierString(KeyValue) - Static method in class org.apache.hadoop.hbase.KeyValueTestUtil
- getQuantiles() - Method in interface org.apache.hadoop.hbase.metrics.Snapshot
-
Return the values with the default quantiles.
- getQuantiles(double[]) - Method in interface org.apache.hadoop.hbase.metrics.Snapshot
-
Return the values with the given quantiles.
- getQuarantined() - Method in class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
-
Returns the set of successfully quarantined paths after checkTables is called.
- getQuarantinedMobFiles() - Method in class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
-
Returns the set of successfully quarantined paths after checkTables is called.
- getQueueId() - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSource
- getQueueId() - Method in class org.apache.hadoop.hbase.replication.ReplicationQueueInfo
- getQueueId() - Method in class org.apache.hadoop.hbase.replication.ZKReplicationQueueStorageForMigration.ZkReplicationQueueData
- getQueueLength() - Method in class org.apache.hadoop.hbase.ipc.RpcExecutor
-
Returns the length of the pending queue
- getQueues() - Method in class org.apache.hadoop.hbase.ipc.RpcExecutor
-
Returns the list of request queues
- getQueueSize() - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
- getQueueSize() - Method in interface org.apache.hadoop.hbase.thrift.IncrementCoalescerMBean
- getQueueTime() - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord
- getQuorum() - Method in class org.apache.hadoop.hbase.zookeeper.ZKWatcher
-
Get the quorum address of this instance.
- getQuorumString() - Method in class org.apache.hadoop.hbase.zookeeper.ZKConfig.ZKClusterKey
- getQuota(QuotaFilter) - Method in interface org.apache.hadoop.hbase.client.Admin
-
List the quotas based on the filter.
- getQuota(QuotaFilter) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
List the quotas based on the filter.
- getQuota(UserGroupInformation, TableName, int) - Method in class org.apache.hadoop.hbase.quotas.RegionServerRpcQuotaManager
-
Returns the quota for an operation.
- getQuotaObserverChore() - Method in class org.apache.hadoop.hbase.master.HMaster
- getQuotaOperationType(ClientProtos.Action, boolean) - Static method in class org.apache.hadoop.hbase.quotas.QuotaUtil
- getQuotaOperationType(ClientProtos.MutateRequest) - Static method in class org.apache.hadoop.hbase.quotas.QuotaUtil
- getQuotaScope() - Method in class org.apache.hadoop.hbase.quotas.ThrottleSettings
- getQuotaSettings() - Method in class org.apache.hadoop.hbase.quotas.GlobalQuotaSettings
-
Computes a list of QuotaSettings that present the complete quota state of the combination of this user, table, and/or namespace.
- getQuotaSettings() - Method in class org.apache.hadoop.hbase.quotas.GlobalQuotaSettingsImpl
- getQuotaSnapshot() - Method in class org.apache.hadoop.hbase.quotas.policies.AbstractViolationPolicyEnforcement
- getQuotaSnapshot() - Method in interface org.apache.hadoop.hbase.quotas.SpaceViolationPolicyEnforcement
-
Returns the
SpaceQuotaSnapshot
this
was initialized with. - getQuotaStates(RpcController, QuotaProtos.GetQuotaStatesRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- getQuotaStatus() - Method in class org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot
-
Returns the status of the quota.
- getQuotaStatus() - Method in interface org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshotView
-
Returns the status of the quota.
- getQuotaType() - Method in class org.apache.hadoop.hbase.quotas.GlobalQuotaSettings
- getQuotaType() - Method in class org.apache.hadoop.hbase.quotas.QuotaSettings
- getQuotaType() - Method in class org.apache.hadoop.hbase.quotas.ThrottleSettings
- getRack(List<ServerName>) - Method in class org.apache.hadoop.hbase.master.RackManager
-
Same as
RackManager.getRack(ServerName)
except that a list is passed - getRack(ServerName) - Method in class org.apache.hadoop.hbase.master.RackManager
-
Get the name of the rack containing a server, according to the DNS to switch mapping.
- getRandomDir() - Method in class org.apache.hadoop.hbase.HBaseCommonTestingUtility
-
Deprecated.
- getRandomKey() - Method in class org.apache.hadoop.hbase.io.crypto.aes.AES
- getRandomKey() - Method in class org.apache.hadoop.hbase.io.crypto.aes.CommonsCryptoAES
- getRandomKey() - Method in class org.apache.hadoop.hbase.io.crypto.Cipher
-
Create a random symmetric key
- getRandomUUID() - Static method in class org.apache.hadoop.hbase.HBaseCommonTestingUtility
-
Deprecated.
- getRange(String, String) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
- getRaw(String) - Method in class org.apache.hadoop.hbase.CompoundConfiguration
- getRaw(String) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
- getReadAvailable() - Method in class org.apache.hadoop.hbase.quotas.DefaultOperationQuota
- getReadAvailable() - Method in interface org.apache.hadoop.hbase.quotas.OperationQuota
-
Returns the number of bytes available to read to avoid exceeding the quota
- getReadAvailable() - Method in interface org.apache.hadoop.hbase.quotas.QuotaLimiter
-
Returns the number of bytes available to read to avoid exceeding the quota
- getReadAvailable() - Method in class org.apache.hadoop.hbase.quotas.TimeBasedLimiter
- getReadConsumed() - Method in class org.apache.hadoop.hbase.quotas.DefaultOperationQuota
- getReadConsumed() - Method in interface org.apache.hadoop.hbase.quotas.OperationQuota
-
Returns the number of bytes consumed from the quota by the operation
- getReader() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
- getReader() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
-
Returns Reader that underlies this Scanner instance.
- getReader() - Method in class org.apache.hadoop.hbase.regionserver.HStoreFile
- getReader(FileStatus, boolean, CancelableProgressable) - Method in class org.apache.hadoop.hbase.wal.WALSplitter
-
Create a new
WALStreamReader
for reading logs to split. - getReaderContext() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileReader
- getReaderPath() - Method in class org.apache.hadoop.hbase.io.FSDataInputStreamWrapper
- getReaderType() - Method in class org.apache.hadoop.hbase.io.hfile.ReaderContext
- getReadLimit() - Method in interface org.apache.hadoop.hbase.quotas.QuotaLimiter
-
Returns the maximum number of bytes ever available to read
- getReadLimit() - Method in class org.apache.hadoop.hbase.quotas.TimeBasedLimiter
- getReadLockCount() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
- getReadNumLimit() - Method in interface org.apache.hadoop.hbase.quotas.QuotaLimiter
-
Returns the maximum number of reads to allow per TimeUnit
- getReadNumLimit() - Method in class org.apache.hadoop.hbase.quotas.TimeBasedLimiter
- getReadOnlyConfiguration() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
- getReadOnlyConfiguration() - Method in class org.apache.hadoop.hbase.regionserver.HStore
- getReadOnlyConfiguration() - Method in interface org.apache.hadoop.hbase.regionserver.Region
- getReadOnlyConfiguration() - Method in interface org.apache.hadoop.hbase.regionserver.Store
- getReadPoint() - Method in interface org.apache.hadoop.hbase.regionserver.ChangedReadersObserver
-
Returns the read point of the current scan
- getReadPoint() - Method in class org.apache.hadoop.hbase.regionserver.MultiVersionConcurrencyControl
- getReadPoint() - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
- getReadPoint(IsolationLevel) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Returns readpoint considering given IsolationLevel.
- getReadQueueLength() - Method in class org.apache.hadoop.hbase.ipc.DelegatingRpcScheduler
- getReadQueueLength() - Method in class org.apache.hadoop.hbase.ipc.FifoRpcScheduler
- getReadQueueLength() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapper
- getReadQueueLength() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapperImpl
- getReadQueueLength() - Method in class org.apache.hadoop.hbase.ipc.RpcExecutor
- getReadQueueLength() - Method in class org.apache.hadoop.hbase.ipc.RpcScheduler
-
Retrieves length of the read queue for metrics when use RWQueueRpcExecutor.
- getReadQueueLength() - Method in class org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
- getReadQueueLength() - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
- getReadRequestCount() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
Returns the number of read requests made to region
- getReadRequestCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
-
Get the total number of read requests that have been issued against this region
- getReadRequestCount() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
- getReadRequestCount() - Method in interface org.apache.hadoop.hbase.UserMetrics
-
Returns the number of read requests made by user
- getReadRequestCount(String) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregate
-
Get the number of read requests that have been issued against this table
- getReadRequestCount(String) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImpl
- getReadRequestCountPerSecond() - Method in class org.apache.hadoop.hbase.hbtop.mode.RequestCountPerSecond
- getReadRequestsCount() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
- getReadRequestsCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the number of read requests to regions hosted on this region server.
- getReadRequestsCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsUserSource.ClientMetrics
- getReadRequestsCount() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Returns read requests count for this region
- getReadRequestsCount() - Method in interface org.apache.hadoop.hbase.ServerMetrics
-
Returns total Number of read requests from the start of the region server.
- getReadRequestsCount() - Method in interface org.apache.hadoop.hbase.UserMetrics.ClientMetrics
- getReadRequestsCount() - Method in class org.apache.hadoop.hbase.UserMetricsBuilder.ClientMetricsImpl
- getReadRequestsRatePerSecond() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the rate of read requests per second to regions hosted on this region server.
- getReadRpcTimeout() - Method in class org.apache.hadoop.hbase.client.ConnectionConfiguration
- getReadRpcTimeout(TimeUnit) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
Get timeout of each rpc read request in this Table instance.
- getReadRpcTimeout(TimeUnit) - Method in interface org.apache.hadoop.hbase.client.Table
-
Get timeout of each rpc read request in this Table instance.
- getReadShare(Configuration) - Method in class org.apache.hadoop.hbase.ipc.MetaRWQueueRpcExecutor
- getReadShare(Configuration) - Method in class org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
- getReadType() - Method in class org.apache.hadoop.hbase.client.ImmutableScan
- getReadType() - Method in class org.apache.hadoop.hbase.client.Scan
-
Returns the read type for this scan
- getReadyToWriteCount() - Method in class org.apache.hadoop.hbase.regionserver.MiniBatchOperationInProgress
- getReason() - Method in class org.apache.hadoop.hbase.client.BalancerRejection
- getReceiveTime() - Method in interface org.apache.hadoop.hbase.ipc.RpcCall
-
Returns The timestamp when the call is constructed.
- getReceiveTime() - Method in class org.apache.hadoop.hbase.ipc.ServerCall
- getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.hbase.mapred.MultiTableSnapshotInputFormat
- getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
-
Builds a TableRecordReader.
- getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.hbase.mapred.TableSnapshotInputFormat
- getRecords() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenModel
- getRecords(ClusterMetrics, List<RecordFilter>) - Method in class org.apache.hadoop.hbase.hbtop.mode.ClientModeStrategy
- getRecords(ClusterMetrics, List<RecordFilter>) - Method in enum class org.apache.hadoop.hbase.hbtop.mode.Mode
- getRecords(ClusterMetrics, List<RecordFilter>) - Method in class org.apache.hadoop.hbase.hbtop.mode.NamespaceModeStrategy
- getRecords(ClusterMetrics, List<RecordFilter>) - Method in class org.apache.hadoop.hbase.hbtop.mode.RegionModeStrategy
- getRecords(ClusterMetrics, List<RecordFilter>) - Method in class org.apache.hadoop.hbase.hbtop.mode.RegionServerModeStrategy
- getRecords(ClusterMetrics, List<RecordFilter>) - Method in class org.apache.hadoop.hbase.hbtop.mode.TableModeStrategy
- getRecords(ClusterMetrics, List<RecordFilter>) - Method in class org.apache.hadoop.hbase.hbtop.mode.UserModeStrategy
- getRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class org.apache.hadoop.hbase.mapred.TableOutputFormat
-
Creates a new record writer.
- getRecordWriter(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
- getRecordWriter(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableOutputFormat
- getRecordWriter(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputFormat
-
Creates a new record writer.
- getRecoverableZooKeeper() - Method in class org.apache.hadoop.hbase.zookeeper.ZKWatcher
-
Get the connection to ZooKeeper.
- getRecoveredHFiles(FileSystem, Path, String) - Static method in class org.apache.hadoop.hbase.wal.WALSplitUtil
- getRecycler() - Method in class org.apache.hadoop.hbase.nio.RefCnt
- getRefCellTags() - Method in class org.apache.hadoop.hbase.regionserver.HMobStore
- getRefCnt() - Method in class org.apache.hadoop.hbase.nio.ByteBuff
- getRefCount() - Method in class org.apache.hadoop.hbase.regionserver.HStoreFile
- getReference() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
- getReferenceAndLinkFilePaths(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
- getReferenceCount() - Method in class org.apache.hadoop.hbase.mob.CachedMobFile
-
Gets the reference of the current mob file.
- getReferencedFileStatus(FileSystem) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
Get the
FileStatus
of the file referenced by this StoreFileInfo - getReferencedHFileName(String) - Static method in class org.apache.hadoop.hbase.io.HFileLink
-
Get the HFile name of the referenced link
- getReferencedRegionName(String) - Static method in class org.apache.hadoop.hbase.io.HFileLink
-
Get the Region name of the referenced link
- getReferencedTableName(String) - Static method in class org.apache.hadoop.hbase.io.HFileLink
-
Get the Table name of the referenced link
- getReferenceFilePaths(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
- getReferenceKey(Reference<V>) - Method in class org.apache.hadoop.hbase.util.ObjectPool
-
Get key of the given reference
- getReferenceKey(Reference<V>) - Method in class org.apache.hadoop.hbase.util.SoftObjectPool
- getReferenceKey(Reference<V>) - Method in class org.apache.hadoop.hbase.util.WeakObjectPool
- getReferenceType() - Method in class org.apache.hadoop.hbase.util.IdReadWriteLockWithObjectPool
- getReferredToFile(Path) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
- getReferredToRegionAndFile(String) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
- getRegex() - Method in class org.apache.hadoop.hbase.client.NormalizeTableFilterParams
- getRegion() - Method in class org.apache.hadoop.hbase.client.RegionCoprocessorServiceExec
- getRegion() - Method in interface org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment
-
Returns the region associated with this coprocessor
- getRegion() - Method in class org.apache.hadoop.hbase.HRegionLocation
-
Returns regionInfo
- getRegion() - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormat.TableSnapshotRegionSplit
- getRegion() - Method in class org.apache.hadoop.hbase.master.RegionState
- getRegion() - Method in class org.apache.hadoop.hbase.regionserver.RegionServerServices.PostOpenDeployContext
- getRegion(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Protected Utility method for safely obtaining an HRegion handle.
- getRegion(String) - Method in class org.apache.hadoop.hbase.MockRegionServerServices
- getRegion(String) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
- getRegion(String) - Method in interface org.apache.hadoop.hbase.regionserver.OnlineRegions
-
Return
Region
instance. - getRegion(String) - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
- getRegion(Connection, byte[]) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Deprecated.use
MetaTableAccessor.getRegionLocation(Connection, byte[])
instead - getRegion(RegionInfo) - Method in interface org.apache.hadoop.hbase.testing.TestingHBaseCluster
-
Get the server side
Region
interface for the specific region. - getRegion(HBaseProtos.RegionSpecifier) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
Find the HRegion based on a region specifier
- getRegion1Info() - Method in class org.apache.hadoop.hbase.HbckOverlapRegions
- getRegion1Info() - Method in class org.apache.hadoop.hbase.HbckRegionHoles
- getRegion2Info() - Method in class org.apache.hadoop.hbase.HbckOverlapRegions
- getRegion2Info() - Method in class org.apache.hadoop.hbase.HbckRegionHoles
- getRegionActionBuilderWithRegion(ClientProtos.RegionAction.Builder, byte[]) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
- getRegionArchiveDir(Path, TableName, String) - Static method in class org.apache.hadoop.hbase.util.HFileArchiveUtil
-
Get the archive directory for a given region under the specified table
- getRegionArchiveDir(Path, TableName, Path) - Static method in class org.apache.hadoop.hbase.util.HFileArchiveUtil
-
Get the archive directory for a given region under the specified table
- getRegionAssignmentSnapshot() - Method in class org.apache.hadoop.hbase.master.RegionPlacementMaintainer
-
Returns the new RegionAssignmentSnapshot
- getRegionByEncodedName(String) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
- getRegionCachedInfo() - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCache
-
Returns an Optional containing a map of regions and the percentage of how much of it has been cached so far.
- getRegionCachedInfo() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
- getRegionCachedInfo() - Method in interface org.apache.hadoop.hbase.ServerMetrics
-
Returns the region cache information for the regions hosted on this server
- getRegionCount() - Method in interface org.apache.hadoop.hbase.ClusterMetrics
-
Returns the number of regions deployed on the cluster
- getRegionCount() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.Summary
- getRegionCountOfTable(TableName) - Method in class org.apache.hadoop.hbase.namespace.NamespaceAuditor
-
Get region count for table
- getRegionCountOfTable(TableName) - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
-
Returns cached region count, or -1 if quota manager is disabled or table status not found
- getRegionCounts() - Method in interface org.apache.hadoop.hbase.master.MetricsMasterWrapper
-
Get the online and offline region counts
- getRegionCounts() - Method in class org.apache.hadoop.hbase.master.MetricsMasterWrapperImpl
- getRegionDebugInfoSafe(Table, byte[]) - Method in class org.apache.hadoop.hbase.util.MultiThreadedWriterBase
- getRegionDegreeLocalityMappingFromFS(Configuration) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
This function is to scan the root path of the file system to get the degree of locality for each region on each of the servers having at least one block of that region.
- getRegionDegreeLocalityMappingFromFS(Configuration, String, int) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
This function is to scan the root path of the file system to get the degree of locality for each region on each of the servers having at least one block of that region.
- getRegionDir() - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
Returns
Path
to the region directory. - getRegionDir(Path, String) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Deprecated.For tests only; to be removed.
- getRegionDir(Path, TableName, String) - Static method in class org.apache.hadoop.hbase.util.CommonFSUtils
-
Returns the
Path
object representing the region directory under path rootdir - getRegionDir(RegionInfo) - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
-
Returns the directory for a give
region
. - getRegionDirFromRootDir(Path, RegionInfo) - Static method in class org.apache.hadoop.hbase.util.FSUtils
- getRegionDirFromTableDir(Path, String) - Static method in class org.apache.hadoop.hbase.util.FSUtils
- getRegionDirFromTableDir(Path, RegionInfo) - Static method in class org.apache.hadoop.hbase.util.FSUtils
- getRegionDirRecoveredEditsDir(Path) - Static method in class org.apache.hadoop.hbase.wal.WALSplitUtil
- getRegionDirs(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Given a particular table dir, return all the regiondirs inside it, excluding files such as .tableinfo
- getRegionEncodedName(HBaseProtos.RegionSpecifier) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Find the HRegion encoded name based on a region specifier
- getRegionEventDescriptor(Cell) - Static method in class org.apache.hadoop.hbase.wal.WALEdit
- getRegionFileSystem() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Returns the
HRegionFileSystem
used by this region - getRegionFileSystem() - Method in class org.apache.hadoop.hbase.regionserver.HStore
- getRegionFileSystem() - Method in class org.apache.hadoop.hbase.regionserver.StoreContext
- getRegionHashCode() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
- getRegionHashCode() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
- getRegionHdfsPath() - Method in class org.apache.hadoop.hbase.HbckOrphanRegionsOnFS
- getRegionId() - Method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Returns the regionId.
- getRegionId() - Method in class org.apache.hadoop.hbase.HbckInconsistentRegions
- getRegionId() - Method in class org.apache.hadoop.hbase.HbckOrphanRegionsOnFS
- getRegionId() - Method in class org.apache.hadoop.hbase.HbckOrphanRegionsOnRS
- getRegionId() - Method in class org.apache.hadoop.hbase.HbckRegionDetails
- getRegionInfo() - Method in interface org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment
-
Returns region information for the region this coprocessor is running on
- getRegionInfo() - Method in class org.apache.hadoop.hbase.HbckEmptyRegionInfo
- getRegionInfo() - Method in class org.apache.hadoop.hbase.HbckUnknownServers
- getRegionInfo() - Method in interface org.apache.hadoop.hbase.ipc.HBaseRpcController
-
Returns Target Region's RegionInfo or null if not available or pertinent.
- getRegionInfo() - Method in class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
- getRegionInfo() - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.InputSplit
- getRegionInfo() - Method in class org.apache.hadoop.hbase.master.RegionPlan
- getRegionInfo() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
- getRegionInfo() - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
Returns the
RegionInfo
that describe this on-disk region view - getRegionInfo() - Method in class org.apache.hadoop.hbase.regionserver.HStore
- getRegionInfo() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Returns region information for this region
- getRegionInfo() - Method in interface org.apache.hadoop.hbase.regionserver.RegionScanner
-
Returns The RegionInfo for this scanner.
- getRegionInfo() - Method in class org.apache.hadoop.hbase.regionserver.RegionServicesForStores
- getRegionInfo() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Returns the parent region info hosting this store
- getRegionInfo() - Method in interface org.apache.hadoop.hbase.regionserver.StoreConfigInformation
- getRegionInfo() - Method in class org.apache.hadoop.hbase.regionserver.StoreContext
- getRegionInfo() - Method in class org.apache.hadoop.hbase.util.HbckRegionInfo.MetaEntry
- getRegionInfo(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
- getRegionInfo(Result) - Static method in class org.apache.hadoop.hbase.CatalogFamilyFormat
-
Returns RegionInfo object from the column HConstants.CATALOG_FAMILY:HConstants.REGIONINFO_QUALIFIER of the catalog table Result.
- getRegionInfo(Result, byte[]) - Static method in class org.apache.hadoop.hbase.CatalogFamilyFormat
-
Returns the RegionInfo object from the column
HConstants.CATALOG_FAMILY
andqualifier
of the catalog table result. - getRegionInfo(AdminProtos.GetRegionInfoRequest) - Method in class org.apache.hadoop.hbase.client.AsyncRegionServerAdmin
- getRegionInfo(RpcController, AdminProtos.AdminService.BlockingInterface, byte[]) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
A helper to retrieve region info given a region name or an encoded region name using admin protocol.
- getRegionInfo(RpcController, AdminProtos.GetRegionInfoRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- getRegionInfo(RpcController, AdminProtos.GetRegionInfoRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
- getRegionInfoForDefaultReplica(RegionInfo) - Static method in class org.apache.hadoop.hbase.client.RegionReplicaUtil
-
Returns the RegionInfo for the default replicaId (0).
- getRegionInfoForFs(RegionInfo) - Static method in class org.apache.hadoop.hbase.util.ServerRegionReplicaUtil
-
Returns the regionInfo object to use for interacting with the file system.
- getRegionInfoForFS() - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
- getRegionInfoForReplica(RegionInfo, int) - Static method in class org.apache.hadoop.hbase.client.RegionReplicaUtil
-
Returns the RegionInfo for the given replicaId.
- getRegionInfos(AdminProtos.GetOnlineRegionResponse) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Get the list of region info from a GetOnlineRegionResponse
- getRegionInfos(AdminProtos.GetOnlineRegionResponse) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ResponseConverter
-
Get the list of region info from a GetOnlineRegionResponse
- getRegionInfosFromManifest(SnapshotManifest) - Static method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl
- getRegionLoad(AdminProtos.GetRegionLoadRequest) - Method in class org.apache.hadoop.hbase.client.AsyncRegionServerAdmin
- getRegionLoad(RpcController, AdminProtos.GetRegionLoadRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- getRegionLoad(RpcController, AdminProtos.GetRegionLoadRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
- getRegionLocation() - Method in class org.apache.hadoop.hbase.mapred.TableSplit
-
Returns the region's hostname
- getRegionLocation() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
-
Returns the region location.
- getRegionLocation() - Method in class org.apache.hadoop.hbase.RegionLocations
-
Returns the first not-null region location in the list
- getRegionLocation(byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncTableRegionLocator
-
Finds the region on which the given row is being served.
- getRegionLocation(byte[]) - Method in interface org.apache.hadoop.hbase.client.RegionLocator
-
Finds the region on which the given row is being served.
- getRegionLocation(byte[], boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncTableRegionLocator
-
Finds the region on which the given row is being served.
- getRegionLocation(byte[], boolean) - Method in interface org.apache.hadoop.hbase.client.RegionLocator
-
Finds the region on which the given row is being served.
- getRegionLocation(byte[], int) - Method in interface org.apache.hadoop.hbase.client.AsyncTableRegionLocator
-
Finds the region with the given
replicaId
on which the given row is being served. - getRegionLocation(byte[], int) - Method in interface org.apache.hadoop.hbase.client.RegionLocator
-
Finds the region with the given replica id on which the given row is being served.
- getRegionLocation(byte[], int, boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncTableRegionLocator
-
Finds the region with the given
replicaId
on which the given row is being served. - getRegionLocation(byte[], int, boolean) - Method in interface org.apache.hadoop.hbase.client.RegionLocator
-
Finds the region with the given replica id on which the given row is being served.
- getRegionLocation(int) - Method in class org.apache.hadoop.hbase.RegionLocations
- getRegionLocation(AsyncTable<?>, byte[]) - Static method in class org.apache.hadoop.hbase.ClientMetaTableAccessor
-
Returns the HRegionLocation from meta for the given region
- getRegionLocation(Connection, byte[]) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Returns the HRegionLocation from meta for the given region
- getRegionLocation(Connection, RegionInfo) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Returns the HRegionLocation from meta for the given region
- getRegionLocation(Result, RegionInfo, int) - Static method in class org.apache.hadoop.hbase.CatalogFamilyFormat
-
Returns the HRegionLocation parsed from the given meta row Result for the given regionInfo and replicaId.
- getRegionLocationByRegionName(byte[]) - Method in class org.apache.hadoop.hbase.RegionLocations
-
Returns the region location from the list for matching regionName, which can be regionName or encodedRegionName
- getRegionLocations() - Method in class org.apache.hadoop.hbase.RegionLocations
- getRegionLocations(byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncTableRegionLocator
-
Find all the replicas for the region on which the given row is being served.
- getRegionLocations(byte[]) - Method in interface org.apache.hadoop.hbase.client.RegionLocator
-
Find all the replicas for the region on which the given row is being served.
- getRegionLocations(byte[], boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncTableRegionLocator
-
Find all the replicas for the region on which the given row is being served.
- getRegionLocations(byte[], boolean) - Method in interface org.apache.hadoop.hbase.client.RegionLocator
-
Find all the replicas for the region on which the given row is being served.
- getRegionLocations(Result) - Static method in class org.apache.hadoop.hbase.CatalogFamilyFormat
-
Returns an HRegionLocationList extracted from the result.
- getRegionLocations(TableName, byte[], boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncClusterConnection
-
Return all the replicas for a region.
- getRegionLocationWithEncodedName(AsyncTable<?>, byte[]) - Static method in class org.apache.hadoop.hbase.ClientMetaTableAccessor
-
Returns the HRegionLocation from meta for the given encoded region name
- getRegionLocator() - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
Gets the
AsyncTableRegionLocator
for this table. - getRegionLocator() - Method in interface org.apache.hadoop.hbase.client.Table
-
Gets the
RegionLocator
for this table. - getRegionLocator() - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
Allows subclasses to get the
RegionLocator
. - getRegionLocator(byte[]) - Method in class org.apache.hadoop.hbase.util.ConnectionCache
-
Retrieve a regionLocator for the table.
- getRegionLocator(TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncConnection
-
Retrieve a AsyncRegionLocator implementation to inspect region information on a table.
- getRegionLocator(TableName) - Method in class org.apache.hadoop.hbase.client.AsyncConnectionImpl
- getRegionLocator(TableName) - Method in interface org.apache.hadoop.hbase.client.Connection
-
Retrieve a RegionLocator implementation to inspect region information on a table.
- getRegionLocator(TableName) - Method in class org.apache.hadoop.hbase.client.SharedAsyncConnection
- getRegionLocator(TableName) - Method in class org.apache.hadoop.hbase.client.SharedConnection
- getRegionManifests() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotManifest
-
Get all the Region Manifest from the snapshot
- getRegionManifestsMap() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotManifest
-
Get all the Region Manifest from the snapshot.
- getRegionMetrics() - Method in interface org.apache.hadoop.hbase.ServerMetrics
-
Returns region load metrics
- getRegionMetrics(ServerName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get
RegionMetrics
of all regions hosted on a regionserver. - getRegionMetrics(ServerName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Get a list of
RegionMetrics
of all regions hosted on a region server. - getRegionMetrics(ServerName, TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get
RegionMetrics
of all regions hosted on a regionserver for a table. - getRegionMetrics(ServerName, TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Get a list of
RegionMetrics
of all regions hosted on a region server for a table. - getRegionName() - Method in class org.apache.hadoop.hbase.client.LogQueryFilter
-
Deprecated.
- getRegionName() - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord
- getRegionName() - Method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Returns the regionName as an array of bytes.
- getRegionName() - Method in class org.apache.hadoop.hbase.client.SlowLogParams
- getRegionName() - Method in class org.apache.hadoop.hbase.master.RegionPlan
-
Get the encoded region name for the region this plan is for.
- getRegionName() - Method in class org.apache.hadoop.hbase.mob.MobFileName
-
Gets region name
- getRegionName() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
Returns the region name
- getRegionName() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
-
Get the name of the region.
- getRegionName() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
- getRegionName() - Method in class org.apache.hadoop.hbase.util.HbckRegionInfo
- getRegionNameAsString() - Method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Returns Region name as a String for use in logging, etc.
- getRegionNameAsString() - Method in class org.apache.hadoop.hbase.util.HbckRegionInfo
- getRegionNameAsString(byte[]) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
- getRegionNameAsString(RegionInfo, byte[]) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
- getRegionNameAsStringForDisplay(RegionInfo, Configuration) - Static method in class org.apache.hadoop.hbase.client.RegionInfoDisplay
-
Get the region name for display.
- getRegionNameForDisplay(RegionInfo, Configuration) - Static method in class org.apache.hadoop.hbase.client.RegionInfoDisplay
-
Get the region name for display.
- getRegionNameToRegionInfoMap() - Method in class org.apache.hadoop.hbase.master.SnapshotOfRegionAssignmentFromMeta
-
Get the regioninfo for a region
- getRegionNormalizerManager() - Method in class org.apache.hadoop.hbase.master.HMaster
- getRegionNormalizerManager() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Returns Master's instance of
RegionNormalizerManager
- getRegionObserver() - Method in class org.apache.hadoop.hbase.backup.BackupObserver
- getRegionObserver() - Method in class org.apache.hadoop.hbase.coprocessor.MetaTableMetrics
- getRegionObserver() - Method in interface org.apache.hadoop.hbase.coprocessor.RegionCoprocessor
- getRegionPlans() - Method in class org.apache.hadoop.hbase.client.BalancerDecision
- getRegionReferenceAndLinkFileCount(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
- getRegionReferenceFileCount(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
- getRegionReplicaStoreFileRefreshMultiplier(Configuration) - Static method in class org.apache.hadoop.hbase.util.ServerRegionReplicaUtil
- getRegionReplication() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
Returns Returns the configured replicas per region
- getRegionReplicationBufferManager() - Method in class org.apache.hadoop.hbase.MockRegionServerServices
- getRegionReplicationBufferManager() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
- getRegionReplicationBufferManager() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
- getRegionReplicationSink() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
- getRegionResult(Connection, RegionInfo) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Gets the result in hbase:meta for the specified region.
- getRegions() - Method in class org.apache.hadoop.hbase.MockRegionServerServices
- getRegions() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
- getRegions() - Method in interface org.apache.hadoop.hbase.regionserver.OnlineRegions
-
Get all online regions in this RS.
- getRegions() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
- getRegions(byte[]) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.
- getRegions(ServerName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get all the online regions on a region server.
- getRegions(ServerName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Get all the online regions on a region server.
- getRegions(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get the regions of a given table.
- getRegions(TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Get the regions of a given table.
- getRegions(TableName) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.
- getRegions(TableName) - Method in class org.apache.hadoop.hbase.MockRegionServerServices
- getRegions(TableName) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Gets the online regions of the specified table.
- getRegions(TableName) - Method in interface org.apache.hadoop.hbase.regionserver.OnlineRegions
-
Get all online regions of a table in this RS.
- getRegions(TableName) - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
- getRegionServer() - Method in class org.apache.hadoop.hbase.quotas.QuotaSettings
- getRegionServer() - Method in class org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint.SinkPeer
- getRegionServer() - Method in class org.apache.hadoop.hbase.util.HbckRegionInfo.MetaEntry
- getRegionServer() - Method in class org.apache.hadoop.hbase.util.JVMClusterUtil.RegionServerThread
-
Returns the region server
- getRegionServer(int) - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
Returns region server
- getRegionServer(int) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.Grab a numbered region server of your choice.
- getRegionServer(ServerName) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.
- getRegionServerAccounting() - Method in class org.apache.hadoop.hbase.MockRegionServerServices
- getRegionServerAccounting() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
- getRegionServerAccounting() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
Returns the RegionServerAccounting for this Region Server
- getRegionServerAddresses() - Method in interface org.apache.hadoop.hbase.testing.TestingHBaseCluster
-
Get all the region server addresses.
- getRegionServerAdmin(ServerName) - Method in interface org.apache.hadoop.hbase.client.AsyncClusterConnection
-
Get the admin service for the given region server.
- getRegionServerCoprocessorHost() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
- getRegionServerCoprocessors() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
- getRegionServerFatalLogBuffer() - Method in class org.apache.hadoop.hbase.master.HMaster
- getRegionServerFilter() - Method in class org.apache.hadoop.hbase.quotas.QuotaFilter
-
Returns the RegionServer filter regex
- getRegionServerFromRowKey(byte[]) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
- getRegionServerGroup() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
Get the region server group this table belongs to.
- getRegionServerIndex(ServerName) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.
- getRegionServerInfoPort(ServerName) - Method in class org.apache.hadoop.hbase.master.HMaster
- getRegionServerObserver() - Method in interface org.apache.hadoop.hbase.coprocessor.RegionServerCoprocessor
- getRegionServerQuota(Connection, String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
- getRegionServerQuotaLimiter(String) - Method in class org.apache.hadoop.hbase.quotas.QuotaCache
-
Returns the limiter associated to the specified region server.
- getRegionServerRowKey(String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
- getRegionServerRpcQuotaManager() - Method in class org.apache.hadoop.hbase.MockRegionServerServices
- getRegionServerRpcQuotaManager() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
- getRegionServerRpcQuotaManager() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
Returns RegionServer's instance of
RegionServerRpcQuotaManager
- getRegionServers() - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get the live server list.
- getRegionServers() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Returns current live region servers list wrapped by
CompletableFuture
- getRegionServers() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
Returns Read-only list of region server threads.
- getRegionServers() - Method in interface org.apache.hadoop.hbase.master.MetricsMasterWrapper
-
Get the live region servers
- getRegionServers() - Method in class org.apache.hadoop.hbase.master.MetricsMasterWrapperImpl
- getRegionServers() - Method in class org.apache.hadoop.hbase.master.RegionServerTracker
- getRegionServers(boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Retrieve all current live region servers including decommissioned if excludeDecommissionedRS is false, else non-decommissioned ones only
- getRegionServers(boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
- getRegionServerServices() - Method in interface org.apache.hadoop.hbase.coprocessor.HasRegionServerServices
-
Deprecated.Returns An instance of RegionServerServices, an object NOT for Coprocessor consumption.
- getRegionServerServices() - Method in class org.apache.hadoop.hbase.quotas.policies.AbstractViolationPolicyEnforcement
- getRegionServerSpaceQuotaManager() - Method in class org.apache.hadoop.hbase.MockRegionServerServices
- getRegionServerSpaceQuotaManager() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
- getRegionServerSpaceQuotaManager() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
Returns RegionServer's instance of
RegionServerSpaceQuotaManager
- getRegionServerSpaceQuotaSnapshots(ServerName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Fetches the observed
SpaceQuotaSnapshotView
s observed by a RegionServer. - getRegionServerSpaceQuotaSnapshots(ServerName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Fetches the observed
SpaceQuotaSnapshotView
s observed by a RegionServer. - getRegionServerThreads() - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.
- getRegionServerToRegionMap() - Method in class org.apache.hadoop.hbase.master.SnapshotOfRegionAssignmentFromMeta
-
Get regionserver to region map
- getRegionServerVersion(ServerName) - Method in class org.apache.hadoop.hbase.master.HMaster
- getRegionServerVersion(ServerName) - Method in interface org.apache.hadoop.hbase.master.MasterServices
- getRegionServerWrapper() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
- getRegionServicesForStores() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Returns store services for this region, to access services required by store level needs
- getRegionsFromMeta(TreeMap<String, HbckRegionInfo>) - Method in class org.apache.hadoop.hbase.util.HbckTableInfo
- getRegionsInTransition() - Method in class org.apache.hadoop.hbase.client.RegionStatesCount
- getRegionsInTransitionInRS() - Method in class org.apache.hadoop.hbase.MockRegionServerServices
- getRegionsInTransitionInRS() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
- getRegionsInTransitionInRS() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
Get the regions that are currently being opened or closed in the RS
- getRegionSize(byte[]) - Method in class org.apache.hadoop.hbase.mapreduce.RegionSizeCalculator
-
Returns size of given region in bytes.
- getRegionSize(RegionInfo) - Method in class org.apache.hadoop.hbase.quotas.NoOpRegionSizeStore
- getRegionSize(RegionInfo) - Method in interface org.apache.hadoop.hbase.quotas.RegionSizeStore
-
Returns the size for the give region if one exists.
- getRegionSize(RegionInfo) - Method in class org.apache.hadoop.hbase.quotas.RegionSizeStoreImpl
- getRegionSizeMap() - Method in class org.apache.hadoop.hbase.mapreduce.RegionSizeCalculator
- getRegionSizeMB() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
Returns the total size of the hfiles in the region
- getRegionSizeStore() - Method in class org.apache.hadoop.hbase.quotas.RegionServerSpaceQuotaManager
-
Returns the
RegionSizeStore
tracking filesystem utilization by each region. - getRegionsMovement(FavoredNodesPlan) - Method in class org.apache.hadoop.hbase.master.RegionPlacementMaintainer
-
Return how many regions will move per table since their primary RS will change
- getRegionsOfFavoredNode(ServerName) - Method in class org.apache.hadoop.hbase.favored.FavoredNodesManager
- getRegionSplitLimit() - Method in class org.apache.hadoop.hbase.regionserver.CompactSplit
-
Returns the regionSplitLimit
- getRegionSplitPolicyClassName() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
This gets the class associated with the region split policy which determines when a region split should occur.
- getRegionSplitStartKeys(byte[], byte[], int) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Create region split keys between startkey and endKey
- getRegionsResource() - Method in class org.apache.hadoop.hbase.rest.TableResource
- getRegionStateColumn(int) - Static method in class org.apache.hadoop.hbase.CatalogFamilyFormat
-
Returns the column qualifier for serialized region state
- getRegionStatesInTransition() - Method in interface org.apache.hadoop.hbase.ClusterMetrics
- getRegionsToAdd() - Method in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper.RestoreMetaChanges
-
Returns the list of new regions added during the on-disk restore.
- getRegionsToRemove() - Method in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper.RestoreMetaChanges
-
Returns the list of regions removed during the on-disk restore.
- getRegionsToRestore() - Method in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper.RestoreMetaChanges
-
Returns the list of 'restored regions' during the on-disk restore.
- getRegionToRegionServerMap() - Method in class org.apache.hadoop.hbase.master.SnapshotOfRegionAssignmentFromMeta
-
Get region to region server map
- getRegionWrapper() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegion
- getRegistredMBeans(ObjectName, MBeanServer) - Static method in class org.apache.hadoop.hbase.util.JSONMetricUtil
- getRejectDecommissionedHostsConfig(Configuration) - Method in class org.apache.hadoop.hbase.master.ServerManager
-
Reads the value of HConstants.REJECT_DECOMMISSIONED_HOSTS_KEY from the config and returns it
- getRemaining() - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
- getRemaining() - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
The number of bytes remaining between position and the end of the range.
- getRemoteAddress() - Method in interface org.apache.hadoop.hbase.ipc.RpcCallContext
-
Returns Address of remote client in this call
- getRemoteAddress() - Static method in class org.apache.hadoop.hbase.ipc.RpcServer
-
Returns the address of the remote client associated with the current RPC request or not present if no address is set.
- getRemoteAddress() - Method in class org.apache.hadoop.hbase.ipc.ServerCall
- getRemoteException(ServiceException) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Return the IOException thrown by the remote server wrapped in ServiceException as cause.
- getRemoteIp() - Static method in class org.apache.hadoop.hbase.ipc.RpcServer
-
Returns the remote side ip address when invoked inside an RPC Returns null incase of an error.
- getRemotePort() - Method in interface org.apache.hadoop.hbase.ipc.RpcCall
-
Returns Port of remote address in this call
- getRemotePort() - Method in class org.apache.hadoop.hbase.ipc.ServerCall
- getRemoteWALDir() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
- getRemoteWALFileSystem(Configuration, String) - Static method in class org.apache.hadoop.hbase.replication.ReplicationUtils
- getReopenMetrics() - Method in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
-
Returns
OperationMetrics
containing common metrics for reopen region operation - getReopenMetrics() - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManagerSourceImpl
- getReopenProcMetrics() - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManager
-
Returns Set of common metrics for reopen procedure
- getReplBarrierFamilyDescForMeta() - Static method in class org.apache.hadoop.hbase.util.FSTableDescriptors
- getReplicableHFiles(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueueStorage
-
Get a list of all hfile references in the given peer.
- getReplicableHFiles(String) - Method in class org.apache.hadoop.hbase.replication.TableReplicationQueueStorage
- getReplicaCallTimeoutMicroSecondScan() - Method in class org.apache.hadoop.hbase.client.ConnectionConfiguration
- getReplicaId() - Method in class org.apache.hadoop.hbase.client.Action
- getReplicaId() - Method in class org.apache.hadoop.hbase.client.ImmutableScan
- getReplicaId() - Method in class org.apache.hadoop.hbase.client.Query
-
Returns region replica id where Query will fetch data from.
- getReplicaId() - Method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Returns returns region replica id
- getReplicaId() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
-
Get the replica id of this region.
- getReplicaId() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
-
Get the replica id of this region.
- getReplicaId() - Method in class org.apache.hadoop.hbase.util.HbckRegionInfo
- getReplicaLoad(List<ServerName>) - Method in class org.apache.hadoop.hbase.favored.FavoredNodesManager
-
Get the replica count for the servers provided.
- getReplicationBarrierResult(Connection, TableName, byte[], byte[]) - Static method in class org.apache.hadoop.hbase.replication.ReplicationBarrierFamilyFormat
- getReplicationBarriers(Connection, byte[]) - Static method in class org.apache.hadoop.hbase.replication.ReplicationBarrierFamilyFormat
- getReplicationBarriers(Result) - Static method in class org.apache.hadoop.hbase.replication.ReplicationBarrierFamilyFormat
- getReplicationEndpointImpl() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
- getReplicationLag() - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSource
- getReplicationLoad(ServerName[]) - Method in class org.apache.hadoop.hbase.master.HMaster
- getReplicationLoadSink() - Method in interface org.apache.hadoop.hbase.ServerMetrics
-
Call directly from client such as hbase shell
- getReplicationLoadSourceList() - Method in interface org.apache.hadoop.hbase.ServerMetrics
-
Call directly from client such as hbase shell
- getReplicationLoadSourceMap() - Method in interface org.apache.hadoop.hbase.ServerMetrics
-
Call directly from client such as hbase shell
- getReplicationLogCleanerBarrier() - Method in class org.apache.hadoop.hbase.master.HMaster
- getReplicationLogCleanerBarrier() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Returns the
ReplicationLogCleanerBarrier
. - getReplicationManager() - Method in interface org.apache.hadoop.hbase.regionserver.ReplicationSourceService
-
Returns the replication manager
- getReplicationPeer() - Method in class org.apache.hadoop.hbase.replication.ReplicationEndpoint.Context
- getReplicationPeerConfig(String) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Returns the configured ReplicationPeerConfig for the specified peer.
- getReplicationPeerConfig(String) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Returns the configured ReplicationPeerConfig for the specified peer
- getReplicationPeerConfig(String) - Method in class org.apache.hadoop.hbase.master.HMaster
- getReplicationPeerConfig(String) - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Returns the configured ReplicationPeerConfig for the specified peer
- getReplicationPeerConfig(RpcController, ReplicationProtos.GetReplicationPeerConfigRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- getReplicationPeerManager() - Method in class org.apache.hadoop.hbase.master.HMaster
- getReplicationPeerManager() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Returns the
ReplicationPeerManager
. - getReplicationPeerModificationProcedures(RpcController, ReplicationProtos.GetReplicationPeerModificationProceduresRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- getReplicationPeers() - Method in interface org.apache.hadoop.hbase.regionserver.ReplicationSourceService
-
Return the replication peers.
- getReplicationPeers(FileSystem, ZKWatcher, Configuration) - Static method in class org.apache.hadoop.hbase.replication.ReplicationFactory
- getReplicationPeerStorage(FileSystem, ZKWatcher, Configuration) - Static method in class org.apache.hadoop.hbase.replication.ReplicationStorageFactory
-
Create a new
ReplicationPeerStorage
. - getReplicationPeerSyncReplicationState(String) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get the current cluster state in a synchronous replication peer.
- getReplicationPeerSyncReplicationState(String) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Get the current cluster state in a synchronous replication peer.
- getReplicationQueueLength() - Method in class org.apache.hadoop.hbase.ipc.DelegatingRpcScheduler
- getReplicationQueueLength() - Method in class org.apache.hadoop.hbase.ipc.FifoRpcScheduler
- getReplicationQueueLength() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapper
- getReplicationQueueLength() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapperImpl
- getReplicationQueueLength() - Method in class org.apache.hadoop.hbase.ipc.RpcScheduler
-
Retrieves length of the replication queue for metrics.
- getReplicationQueueLength() - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
- getReplicationQueueStorage(Connection, Configuration) - Static method in class org.apache.hadoop.hbase.replication.ReplicationStorageFactory
-
Create a new
ReplicationQueueStorage
. - getReplicationQueueStorage(Connection, Configuration, TableName) - Static method in class org.apache.hadoop.hbase.replication.ReplicationStorageFactory
-
Create a new
ReplicationQueueStorage
. - getReplicationScope() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
- getReplicationScopes() - Method in class org.apache.hadoop.hbase.wal.WALKeyImpl
- getReplicationSink() - Method in class org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint
-
Get a randomly-chosen replication sink to replicate to.
- getReplicationSinkService() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Returns Return the object that implements the replication sink executorService.
- getReplicationSourceService() - Method in class org.apache.hadoop.hbase.MockRegionServerServices
- getReplicationSourceService() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Returns Return the object that implements the replication source executorService.
- getReplicationSourceService() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
Returns Return the object that implements the replication source executorService.
- getReplicationZnodesDump(ZKWatcher) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKDump
-
Returns a string with replication znodes and position of the replication log
- getReportTimestamp() - Method in interface org.apache.hadoop.hbase.ServerMetrics
-
Returns the timestamp (server side) of generating this metrics
- getRequest() - Method in class org.apache.hadoop.hbase.client.RegionCoprocessorServiceExec
- getRequest(Service, Descriptors.MethodDescriptor, ByteString) - Static method in class org.apache.hadoop.hbase.ipc.CoprocessorRpcUtils
- getRequestAttribute(String) - Method in interface org.apache.hadoop.hbase.ipc.RpcCall
-
Returns a single request attribute value, or null if no value is present.
- getRequestAttribute(String) - Method in class org.apache.hadoop.hbase.ipc.ServerCall
- getRequestAttributes() - Method in interface org.apache.hadoop.hbase.client.AsyncBufferedMutator
-
Returns the rpc request attributes.
- getRequestAttributes() - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
Get the map of request attributes
- getRequestAttributes() - Method in interface org.apache.hadoop.hbase.client.BufferedMutator
-
Returns the rpc request attributes.
- getRequestAttributes() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
- getRequestAttributes() - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord
- getRequestAttributes() - Method in interface org.apache.hadoop.hbase.client.Table
-
Get the attributes to be submitted with requests
- getRequestAttributes() - Method in class org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
- getRequestAttributes() - Method in interface org.apache.hadoop.hbase.ipc.HBaseRpcController
-
Get the map of request attributes
- getRequestAttributes() - Method in class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
- getRequestAttributes() - Method in interface org.apache.hadoop.hbase.ipc.RpcCall
-
Returns the map of attributes specified when building the request.
- getRequestAttributes() - Method in class org.apache.hadoop.hbase.ipc.ServerCall
- getRequestAttributes() - Method in class org.apache.hadoop.hbase.namequeues.RpcLogDetails
- getRequestCachingCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
- getRequestCachingCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
- getRequestCount() - Method in interface org.apache.hadoop.hbase.ClusterMetrics
-
Returns the number of requests since last report
- getRequestCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
- getRequestCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
- getRequestCount() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
Returns the number of write requests and read requests and coprocessor service requests made to region
- getRequestCount() - Method in interface org.apache.hadoop.hbase.ServerMetrics
-
Returns total Number of requests from the start of the region server.
- getRequestCount() - Method in interface org.apache.hadoop.hbase.UserMetrics
-
Returns the number of write requests and read requests and coprocessor service requests made by the user
- getRequestCountPerSecond() - Method in class org.apache.hadoop.hbase.hbtop.mode.RequestCountPerSecond
- getRequestCountPerSecond() - Method in interface org.apache.hadoop.hbase.ServerMetrics
-
Returns the number of requests per second.
- getRequestData() - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
-
This method should return any additional data that is needed on the server side to construct the ColumnInterpreter.
- getRequestLog(String) - Static method in class org.apache.hadoop.hbase.http.HttpRequestLog
- getRequestNumLimit() - Method in interface org.apache.hadoop.hbase.quotas.QuotaLimiter
-
Returns the maximum number of requests to allow per TimeUnit
- getRequestNumLimit() - Method in class org.apache.hadoop.hbase.quotas.TimeBasedLimiter
- getRequestsCount() - Method in class org.apache.hadoop.hbase.io.hfile.BloomFilterMetrics
-
Returns Current value for bloom requests count
- getRequestSizeBytes() - Method in class org.apache.hadoop.hbase.client.MetricsConnection.CallStats
- getRequestsPerSecond() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the number of requests per second.
- getRequestURL() - Method in class org.apache.hadoop.hbase.http.HttpServer.QuotingInputFilter.RequestQuoter
-
Quote the url so that users specifying the HOST HTTP header can't inject attacks.
- getRequestUser() - Method in interface org.apache.hadoop.hbase.ipc.RpcCallContext
-
Returns the user credentials associated with the current RPC request or not present if no credentials were provided.
- getRequestUser() - Static method in class org.apache.hadoop.hbase.ipc.RpcServer
-
Returns the user credentials associated with the current RPC request or not present if no credentials were provided.
- getRequestUser() - Method in class org.apache.hadoop.hbase.ipc.ServerCall
- getRequestUserName() - Method in interface org.apache.hadoop.hbase.ipc.RpcCallContext
-
Returns Current request's user name or not present if none ongoing.
- getRequestUserName() - Static method in class org.apache.hadoop.hbase.ipc.RpcServer
-
Returns the username for any user associated with the current RPC request or not present if no user is set.
- getRescanNode(ZKWatcher) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog
-
Deprecated.
- getResource(String) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
- getResource(String) - Method in class org.apache.hadoop.hbase.util.CoprocessorClassLoader
- getResponse() - Method in class org.apache.hadoop.hbase.ipc.ServerCall
- getResponse(ClientProtos.CoprocessorServiceResponse, Message) - Static method in class org.apache.hadoop.hbase.ipc.CoprocessorRpcUtils
- getResponse(Message, byte[]) - Static method in class org.apache.hadoop.hbase.ipc.CoprocessorRpcUtils
- getResponseBody(HttpResponse) - Static method in class org.apache.hadoop.hbase.rest.client.Client
-
Returns the response body of the HTTPResponse, if any, as an array of bytes.
- getResponseCellSize() - Method in interface org.apache.hadoop.hbase.ipc.RpcCallContext
-
The size of response cells that have been accumulated so far.
- getResponseCellSize() - Method in class org.apache.hadoop.hbase.ipc.ServerCall
- getResponseExceptionSize() - Method in interface org.apache.hadoop.hbase.ipc.RpcCallContext
- getResponseExceptionSize() - Method in class org.apache.hadoop.hbase.ipc.ServerCall
- getResponseSize() - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord
- getResponseSize() - Method in class org.apache.hadoop.hbase.namequeues.RpcLogDetails
- getResponseSizeBytes() - Method in class org.apache.hadoop.hbase.client.MetricsConnection.CallStats
- getRestoreDir() - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.InputSplit
- getRestoreJob(Configuration) - Static method in class org.apache.hadoop.hbase.backup.BackupRestoreFactory
-
Gets backup restore job
- getRestoreRootDir() - Method in class org.apache.hadoop.hbase.backup.RestoreRequest
- getRestrictedSplitPoint(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.DelimitedKeyPrefixRegionSplitRestriction
- getRestrictedSplitPoint(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.KeyPrefixRegionSplitRestriction
- getRestrictedSplitPoint(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.NoRegionSplitRestriction
- getRestrictedSplitPoint(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.RegionSplitRestriction
-
Returns a restricted split point.
- getResult() - Method in class org.apache.hadoop.hbase.client.CheckAndMutateResult
-
Returns It is used only for CheckAndMutate operations with Increment/Append.
- getResult() - Method in class org.apache.hadoop.hbase.client.SingleResponse.Entry
- getResult() - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost.ObserverOperationWithResult
- getResult() - Method in interface org.apache.hadoop.hbase.regionserver.HRegion.FlushResult
-
Returns the detailed result code
- getResult() - Method in class org.apache.hadoop.hbase.regionserver.HRegion.FlushResultImpl
- getResult() - Method in class org.apache.hadoop.hbase.regionserver.HRegion.PrepareFlushResult
- getResult() - Method in class org.apache.hadoop.hbase.regionserver.OperationStatus
- getResult() - Method in enum class org.apache.hadoop.hbase.wal.WALTailingReader.State
- getResult(ClientProtos.MutateRequest, ClientProtos.MutateResponse, CellScanner) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ResponseConverter
- getResults() - Method in class org.apache.hadoop.hbase.client.MultiResponse
- getResults() - Method in class org.apache.hadoop.hbase.rest.MultiRowResultReader
- getResults(CellScanner, ClientProtos.ScanResponse) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ResponseConverter
-
Create Results from the cells using the cells meta data.
- getResults(ClientProtos.MultiRequest, Map<Integer, Integer>, ClientProtos.MultiResponse, CellScanner) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ResponseConverter
-
Get the results from a protocol buffer MultiResponse
- getResults(ClientProtos.MultiRequest, ClientProtos.MultiResponse, CellScanner) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ResponseConverter
-
Get the results from a protocol buffer MultiResponse
- getRetainedRegionRWRequestsCnt() - Method in class org.apache.hadoop.hbase.regionserver.RegionServerAccounting
-
Returns the retained metrics of region's read and write requests count
- getRetCode() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- getRetriesNumber() - Method in class org.apache.hadoop.hbase.client.ConnectionConfiguration
- getRetryPauseTime() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Return pause time configured in
HConstants.HBASE_RPC_SHORTOPERATION_RETRY_PAUSE_TIME
} - getRevision() - Static method in class org.apache.hadoop.hbase.util.VersionInfo
-
Get the subversion revision number for the root directory
- getRitCount() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.Summary
- getRitDuration() - Method in class org.apache.hadoop.hbase.master.RegionState
- getRootBlockCount() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileIndexBlockEncoder.EncodedSeeker
- getRootBlockCount() - Method in class org.apache.hadoop.hbase.io.hfile.NoOpIndexBlockEncoder.NoOpEncodedSeeker
- getRootBlockKey(int) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileIndexBlockEncoder.EncodedSeeker
- getRootBlockKey(int) - Method in class org.apache.hadoop.hbase.io.hfile.NoOpIndexBlockEncoder.NoOpEncodedSeeker
- getRootDir() - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
-
Returns HBase root dir.
- getRootDir(Configuration) - Static method in class org.apache.hadoop.hbase.util.CommonFSUtils
-
Get the path for the root data directory
- getRootDirFileSystem(Configuration) - Static method in class org.apache.hadoop.hbase.util.CommonFSUtils
- getRootIndexHitCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
- getRootIndexHitCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
- getRootIndexHitCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
- getRootIndexMissCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
- getRootIndexMissCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
- getRootIndexMissCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
- getRootSize() - Method in interface org.apache.hadoop.hbase.io.hfile.BlockIndexChunk
- getRow() - Method in class org.apache.hadoop.hbase.client.CheckAndMutate
-
Returns the row
- getRow() - Method in class org.apache.hadoop.hbase.client.Cursor
- getRow() - Method in class org.apache.hadoop.hbase.client.Get
-
Method for retrieving the get's row
- getRow() - Method in class org.apache.hadoop.hbase.client.Mutation
-
Method for retrieving the delete's row
- getRow() - Method in class org.apache.hadoop.hbase.client.RegionCoprocessorServiceExec
- getRow() - Method in class org.apache.hadoop.hbase.client.Result
-
Method for retrieving the row key that corresponds to the row from which this Result was created.
- getRow() - Method in interface org.apache.hadoop.hbase.client.Row
-
Returns The row.
- getRow() - Method in class org.apache.hadoop.hbase.client.RowMutations
- getRow() - Method in class org.apache.hadoop.hbase.hbtop.terminal.CursorPosition
- getRow() - Method in class org.apache.hadoop.hbase.rest.RowSpec
- getRow(int) - Method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
- getRow(ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
- getRow(Get, long, byte[]) - Method in class org.apache.hadoop.hbase.util.MultiThreadedUpdater.HBaseUpdaterThread
- getRow(Get, long, byte[]) - Method in class org.apache.hadoop.hbase.util.MultiThreadedUpdaterWithACL.HBaseUpdaterThreadWithACL
- getRowArray() - Method in class org.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValue
- getRowArray() - Method in class org.apache.hadoop.hbase.ByteBufferKeyValue
- getRowArray() - Method in interface org.apache.hadoop.hbase.Cell
-
Contiguous raw bytes that may start at any index in the containing array.
- getRowArray() - Method in class org.apache.hadoop.hbase.IndividualBytesFieldCell
-
Implement Cell interface
- getRowArray() - Method in class org.apache.hadoop.hbase.KeyValue
-
Returns the backing array of the entire KeyValue (all KeyValue fields are in a single array)
- getRowArray() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
- getRowArray() - Method in class org.apache.hadoop.hbase.util.MapReduceExtendedCell
- getRowAsInt(Cell) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
Converts the rowkey bytes of the given cell into an int value
- getRowByte(Cell, int) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
misc
- getRowByteBuffer() - Method in class org.apache.hadoop.hbase.ByteBufferExtendedCell
-
Returns The
ByteBuffer
containing the row bytes. - getRowByteBuffer() - Method in class org.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValue
- getRowByteBuffer() - Method in class org.apache.hadoop.hbase.ByteBufferKeyValue
- getRowByteBuffer() - Method in class org.apache.hadoop.hbase.util.MapReduceExtendedCell
- getRowForRegion(RegionInfo) - Static method in class org.apache.hadoop.hbase.wal.WALEdit
- getRowKey(WALEventTrackerPayload) - Static method in class org.apache.hadoop.hbase.namequeues.WALEventTrackerTableAccessor
-
Create rowKey: 1.
- getRowKeyColumnIndex() - Method in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
- getRowLength() - Method in class org.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValue
- getRowLength() - Method in class org.apache.hadoop.hbase.ByteBufferKeyValue
- getRowLength() - Method in interface org.apache.hadoop.hbase.Cell
-
Returns Number of row bytes.
- getRowLength() - Method in class org.apache.hadoop.hbase.IndividualBytesFieldCell
- getRowLength() - Method in class org.apache.hadoop.hbase.KeyValue
-
Returns Row length
- getRowLength() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
- getRowLength() - Method in class org.apache.hadoop.hbase.SizeCachedByteBufferKeyValue
- getRowLength() - Method in class org.apache.hadoop.hbase.SizeCachedKeyValue
- getRowLength() - Method in class org.apache.hadoop.hbase.SizeCachedNoTagsByteBufferKeyValue
- getRowLength() - Method in class org.apache.hadoop.hbase.util.MapReduceExtendedCell
- getRowLock(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Get an exclusive ( write lock ) lock on a given row.
- getRowLock(byte[], boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
- getRowLock(byte[], boolean) - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Get a row lock for the specified row.
- getRowLockInternal(byte[], boolean, Region.RowLock) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
- getRowOffset() - Method in class org.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValue
- getRowOffset() - Method in class org.apache.hadoop.hbase.ByteBufferKeyValue
- getRowOffset() - Method in interface org.apache.hadoop.hbase.Cell
-
Returns Array index of first row byte
- getRowOffset() - Method in class org.apache.hadoop.hbase.IndividualBytesFieldCell
- getRowOffset() - Method in class org.apache.hadoop.hbase.KeyValue
-
Returns Row offset
- getRowOffset() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
- getRowOffset() - Method in class org.apache.hadoop.hbase.util.MapReduceExtendedCell
- getRowOffsetPerColumnFamily() - Method in class org.apache.hadoop.hbase.client.Get
-
Method for retrieving the get's offset per row per column family (#kvs to be skipped)
- getRowOffsetPerColumnFamily() - Method in class org.apache.hadoop.hbase.client.ImmutableScan
- getRowOffsetPerColumnFamily() - Method in class org.apache.hadoop.hbase.client.Scan
-
Method for retrieving the scan's offset per row per column family (#kvs to be skipped)
- getRowPosition() - Method in class org.apache.hadoop.hbase.ByteBufferExtendedCell
-
Returns Position in the
ByteBuffer
where row bytes start - getRowPosition() - Method in class org.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValue
- getRowPosition() - Method in class org.apache.hadoop.hbase.ByteBufferKeyValue
- getRowPosition() - Method in class org.apache.hadoop.hbase.util.MapReduceExtendedCell
- getRowRanges() - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter
- getRowResource(String, String, String, String, String, String) - Method in class org.apache.hadoop.hbase.rest.TableResource
- getRowResourceWithSuffixGlobbing(String, String, String, String, String, String) - Method in class org.apache.hadoop.hbase.rest.TableResource
- getRows() - Method in class org.apache.hadoop.hbase.hbtop.terminal.TerminalSize
- getRows(ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
- getRowString(KeyValue) - Static method in class org.apache.hadoop.hbase.KeyValueTestUtil
- getRowsTs(ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
- getRowsWithColumns(ByteBuffer, List<ByteBuffer>, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
- getRowsWithColumnsTs(ByteBuffer, List<ByteBuffer>, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
- getRowTs(ByteBuffer, ByteBuffer, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
- getRowWithColumns(ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
- getRowWithColumnsTs(ByteBuffer, ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
- getRpcCall() - Method in class org.apache.hadoop.hbase.ipc.CallRunner
- getRpcCall() - Method in class org.apache.hadoop.hbase.namequeues.RpcLogDetails
- getRpcClient() - Method in interface org.apache.hadoop.hbase.client.AsyncClusterConnection
-
Get the rpc client we used to communicate with other servers.
- getRpcConnnectionURI() - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- getRpcCounters() - Method in class org.apache.hadoop.hbase.client.MetricsConnection
-
rpcCounters metric
- getRpcFullScanRequestsCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the number of full region rpc scan requests to this region server.
- getRpcGetRequestsCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the number of rpc get requests to this region server.
- getRpcHistograms() - Method in class org.apache.hadoop.hbase.client.MetricsConnection
-
rpcHistograms metric
- getRpcMultiRequestsCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the number of rpc multi requests to this region server.
- getRpcMutateRequestsCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the number of rpc mutate requests to this region server.
- getRpcName(Descriptors.MethodDescriptor) - Static method in class org.apache.hadoop.hbase.client.trace.IpcClientSpanBuilder
-
Retrieve the
$method
value frommd
. - getRpcPackageAndService(Descriptors.ServiceDescriptor) - Static method in class org.apache.hadoop.hbase.client.trace.IpcClientSpanBuilder
-
Retrieve the combined
$package.$service
value fromsd
. - getRpcQuotaManager() - Method in interface org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment
-
Returns an RpcQuotaManager that can be used to apply quota checks against the workloads generated by the coprocessor.
- getRpcRefCount(BlockCacheKey) - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
- getRpcScanRequestsCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the number of rpc scan requests to this region server.
- getRpcScheduler() - Method in class org.apache.hadoop.hbase.HBaseRpcServicesBase
- getRpcSchedulerFactoryClass() - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
- getRpcSchedulerFactoryClass(Configuration) - Method in class org.apache.hadoop.hbase.HBaseRpcServicesBase
- getRpcSchedulerFactoryClass(Configuration) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- getRpcSchedulerFactoryClass(Configuration) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
- getRpcServer() - Method in class org.apache.hadoop.hbase.HBaseRpcServicesBase
- getRpcServer() - Method in class org.apache.hadoop.hbase.HBaseServerBase
- getRpcServer() - Method in class org.apache.hadoop.hbase.MockRegionServerServices
- getRpcServer() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
Returns a reference to the region server's RPC server
- getRpcServices() - Method in class org.apache.hadoop.hbase.HBaseServerBase
- getRpcTimeout() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
- getRpcTimeout() - Method in class org.apache.hadoop.hbase.client.ConnectionConfiguration
- getRpcTimeout(TimeUnit) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
Get timeout of each rpc request in this Table instance.
- getRpcTimeout(TimeUnit) - Method in interface org.apache.hadoop.hbase.client.Table
-
Get timeout of each rpc request in this Table instance.
- getRpcTimers() - Method in class org.apache.hadoop.hbase.client.MetricsConnection
-
rpcTimers metric
- getRsClass() - Method in class org.apache.hadoop.hbase.StartMiniClusterOption
-
Deprecated.
- getRSForFirstRegionInTable(TableName) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Tool to get the reference to the region server object that holds the region of the specified user table.
- getRSGroup(String) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get group info for the given group name
- getRSGroup(String) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Get group info for the given group name
- getRSGroup(String) - Method in interface org.apache.hadoop.hbase.rsgroup.RSGroupInfoManager
-
Gets
RSGroupInfo
for the given group name. - getRSGroup(Address) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get group info for the given hostPort
- getRSGroup(Address) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Get group info for the given hostPort
- getRSGroup(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get group info for the given table
- getRSGroup(TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Get group info for the given table
- getRSGroupForTable(TableName) - Method in interface org.apache.hadoop.hbase.rsgroup.RSGroupInfoManager
-
Get
RSGroupInfo
for the given table. - getRSGroupInfo(String) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminClient
-
Deprecated.Gets
RSGroupInfo
for given group name. - getRSGroupInfo(MasterServices, RSGroupInfoManager, TableName) - Static method in class org.apache.hadoop.hbase.rsgroup.RSGroupUtil
-
Will try to get the rsgroup from
TableDescriptor
first, and then try to get the rsgroup from theNamespaceDescriptor
. - getRSGroupInfo(RpcController, RSGroupAdminProtos.GetRSGroupInfoRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- getRSGroupInfoManager() - Method in class org.apache.hadoop.hbase.master.HMaster
- getRSGroupInfoManager() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Returns the
RSGroupInfoManager
- getRSGroupInfoOfServer(RpcController, RSGroupAdminProtos.GetRSGroupInfoOfServerRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- getRSGroupInfoOfTable(TableName) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminClient
-
Deprecated.Gets
RSGroupInfo
for the given table's group. - getRSGroupInfoOfTable(RpcController, RSGroupAdminProtos.GetRSGroupInfoOfTableRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- getRSGroupOfServer(Address) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminClient
-
Deprecated.Retrieve the RSGroupInfo a server is affiliated to
- getRSGroupOfServer(Address) - Method in interface org.apache.hadoop.hbase.rsgroup.RSGroupInfoManager
-
Gets the group info of server.
- getRSMobFileCleanerChore() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
- getRsName() - Method in class org.apache.hadoop.hbase.HbckOrphanRegionsOnRS
- getRsName() - Method in class org.apache.hadoop.hbase.namequeues.WALEventTrackerPayload
- getRsPath(ServerName) - Method in class org.apache.hadoop.hbase.zookeeper.ZNodePaths
- getRsPorts() - Method in class org.apache.hadoop.hbase.StartMiniClusterOption
-
Deprecated.
- getRsPorts() - Method in class org.apache.hadoop.hbase.testing.TestingHBaseClusterOption
- getRSRpcServices() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
- getRunnerStats() - Method in class org.apache.hadoop.hbase.client.MetricsConnection
-
runnerStats metric
- getSamplingResult() - Method in class org.apache.hadoop.hbase.util.ReservoirSample
- getSaslQop() - Method in enum class org.apache.hadoop.hbase.security.SaslUtil.QualityOfProtection
- getSaslQOP() - Method in class org.apache.hadoop.hbase.security.HBaseSaslRpcClient
- getSaslQOP() - Method in class org.apache.hadoop.hbase.security.NettyHBaseSaslRpcClient
- getScan() - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord
-
If "hbase.slowlog.scan.payload.enabled" is enabled then this value may be present and should represent the Scan that produced the given
OnlineLogRecord
- getScan() - Method in class org.apache.hadoop.hbase.client.SlowLogParams
- getScan() - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
Gets the scan defining the actual details like columns etc.
- getScan() - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.InputSplit
- getScan() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
-
Returns a Scan object from the stored string representation.
- getScan() - Method in class org.apache.hadoop.hbase.regionserver.CustomizedScanInfoBuilder
- getScan() - Method in interface org.apache.hadoop.hbase.regionserver.ScanOptions
-
Returns a copy of the Scan object.
- getScanAsString() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
-
Returns a scan string
- getScanDetailsWithId(long) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
- getScanDetailsWithRequest(ClientProtos.ScanRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
- getScanForTableName(Configuration, TableName) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
This method creates a Scan object that will only scan catalog rows that belong to the specified table.
- getScanInfo() - Method in class org.apache.hadoop.hbase.regionserver.HStore
- getScanMetrics() - Method in class org.apache.hadoop.hbase.client.AbstractClientScanner
-
Used internally accumulating metrics on scan.
- getScanMetrics() - Method in interface org.apache.hadoop.hbase.client.ResultScanner
-
Returns the scan metrics, or
null
if we do not enable metrics. - getScanMetrics(ClientProtos.ScanResponse) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ResponseConverter
- getScanner() - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.RecordReader
- getScanner() - Method in class org.apache.hadoop.hbase.mob.MobFile
-
Internal use only.
- getScanner() - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler.ResultScannerWrapper
- getScanner(boolean, boolean, boolean) - Method in class org.apache.hadoop.hbase.io.HalfStoreFileReader
- getScanner(boolean, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileReader
-
Will be overridden in HalfStoreFileReader
- getScanner(byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
Gets a scanner on the current table for the given family.
- getScanner(byte[]) - Method in interface org.apache.hadoop.hbase.client.Table
-
Gets a scanner on the current table for the given family.
- getScanner(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
Gets a scanner on the current table for the given family and qualifier.
- getScanner(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.client.Table
-
Gets a scanner on the current table for the given family and qualifier.
- getScanner(long) - Method in class org.apache.hadoop.hbase.regionserver.CompositeImmutableSegment
-
Creates the scanner for the given read point
- getScanner(long) - Method in class org.apache.hadoop.hbase.regionserver.Segment
-
Creates the scanner for the given read point
- getScanner(Configuration, boolean, boolean) - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
- getScanner(Configuration, boolean, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
-
Create a Scanner on this file.
- getScanner(Configuration, boolean, boolean, boolean) - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
- getScanner(Configuration, boolean, boolean, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
-
Create a Scanner on this file.
- getScanner(Scan) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
Returns a scanner on the current table as specified by the
Scan
object. - getScanner(Scan) - Method in interface org.apache.hadoop.hbase.client.Table
-
Returns a scanner on the current table as specified by the
Scan
object. - getScanner(Scan) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
- getScanner(Scan) - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Return an iterator that scans over the HRegion, returning the indicated columns and rows specified by the
Scan
. - getScanner(Scan, List<KeyValueScanner>) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
- getScanner(Scan, List<KeyValueScanner>) - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Return an iterator that scans over the HRegion, returning the indicated columns and rows specified by the
Scan
. - getScanner(Scan, NavigableSet<byte[]>, long) - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
Return a scanner for both the memstore and the HStore files.
- getScannerCaching() - Method in class org.apache.hadoop.hbase.client.ConnectionConfiguration
- getScannerInstanceResource(String) - Method in class org.apache.hadoop.hbase.rest.ScannerResource
- getScannerMaxResultSize() - Method in class org.apache.hadoop.hbase.client.ConnectionConfiguration
- getScannerOrder() - Method in interface org.apache.hadoop.hbase.regionserver.KeyValueScanner
-
Get the order of this KeyValueScanner.
- getScannerOrder() - Method in class org.apache.hadoop.hbase.regionserver.SnapshotSegmentScanner
- getScannerOrder() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
- getScannerResource() - Method in class org.apache.hadoop.hbase.rest.TableResource
- getScanners() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreSnapshot
-
Create new
SnapshotSegmentScanner
s for iterating over the snapshot. - getScanners(boolean, boolean, boolean, boolean, ScanQueryMatcher, byte[], byte[], long, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
Get all scanners with no filtering based on TTL (that happens further down the line).
- getScanners(boolean, boolean, boolean, ScanQueryMatcher, byte[], boolean, byte[], boolean, long, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
Get all scanners with no filtering based on TTL (that happens further down the line).
- getScanners(long) - Method in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
-
This method is protected under
HStore#lock
read lock. - getScanners(long) - Method in class org.apache.hadoop.hbase.regionserver.CompositeImmutableSegment
- getScanners(long) - Method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore
- getScanners(long) - Method in interface org.apache.hadoop.hbase.regionserver.MemStore
- getScanners(long) - Method in class org.apache.hadoop.hbase.regionserver.Segment
- getScanners(List<HStoreFile>, boolean, boolean, boolean, boolean, ScanQueryMatcher, byte[], byte[], long, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
Create scanners on the given files and if needed on the memstore with no filtering based on TTL (that happens further down the line).
- getScanners(List<HStoreFile>, boolean, boolean, boolean, ScanQueryMatcher, byte[], boolean, byte[], boolean, long, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
Create scanners on the given files and if needed on the memstore with no filtering based on TTL (that happens further down the line).
- getScannersCount() - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
- getScannersForCompaction(Collection<HStoreFile>, boolean, long) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
-
Get scanners for compaction.
- getScannersForStoreFiles(Collection<HStoreFile>, boolean, boolean, boolean, boolean, long) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
-
Return an array of scanners corresponding to the given set of store files.
- getScannersForStoreFiles(Collection<HStoreFile>, boolean, boolean, boolean, boolean, ScanQueryMatcher, long) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
-
Return an array of scanners corresponding to the given set of store files, And set the ScanQueryMatcher for each store file scanner for further optimization
- getScanPrefix(String) - Static method in class org.apache.hadoop.hbase.replication.ReplicationQueueId
- getScanPrefix(ServerName, String) - Static method in class org.apache.hadoop.hbase.replication.ReplicationQueueId
- getScanQueueLength() - Method in class org.apache.hadoop.hbase.ipc.DelegatingRpcScheduler
- getScanQueueLength() - Method in class org.apache.hadoop.hbase.ipc.FifoRpcScheduler
- getScanQueueLength() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapper
- getScanQueueLength() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapperImpl
- getScanQueueLength() - Method in class org.apache.hadoop.hbase.ipc.RpcExecutor
- getScanQueueLength() - Method in class org.apache.hadoop.hbase.ipc.RpcScheduler
-
Retrieves length of the scan queue for metrics when use RWQueueRpcExecutor.
- getScanQueueLength() - Method in class org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
- getScanQueueLength() - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
- getScanReadConsumeEstimate(long, long, long, long, long) - Static method in class org.apache.hadoop.hbase.quotas.DefaultOperationQuota
- getScanResource(String, int, String, String, List<String>, int, int, long, long, boolean, boolean, String, String) - Method in class org.apache.hadoop.hbase.rest.TableResource
- getScans() - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableInputFormatBase
-
Allows subclasses to get the list of
Scan
objects. - getScanShare(Configuration) - Method in class org.apache.hadoop.hbase.ipc.MetaRWQueueRpcExecutor
- getScanShare(Configuration) - Method in class org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
- getScanStartRowForNextPeerId(String) - Static method in class org.apache.hadoop.hbase.replication.ReplicationQueueId
- getScanTimeout(TimeUnit) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
Get the timeout of a single operation in a scan.
- getScanTracker() - Method in class org.apache.hadoop.hbase.client.MetricsConnection
-
scanTracker metric
- getScheduler() - Method in class org.apache.hadoop.hbase.ipc.RpcServer
- getScheduler() - Method in interface org.apache.hadoop.hbase.ipc.RpcServerInterface
- getSchemaAlterStatus(RpcController, MasterProtos.GetSchemaAlterStatusRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
Get the number of regions of the table that have been updated by the alter.
- getSchemaResource() - Method in class org.apache.hadoop.hbase.rest.TableResource
- getScheme() - Method in interface org.apache.hadoop.hbase.client.ConnectionRegistryURIFactory
-
The scheme for this implementation.
- getScheme() - Method in class org.apache.hadoop.hbase.client.RpcConnectionRegistryURIFactory
- getScheme() - Method in class org.apache.hadoop.hbase.client.ZKConnectionRegistryURIFactory
- getScheme(HttpConfig.Policy) - Method in class org.apache.hadoop.hbase.http.HttpConfig
- getSchemePrefix() - Method in class org.apache.hadoop.hbase.http.HttpConfig
- getScope() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Returns the scope tag
- getScopeWALEntryFilter() - Method in class org.apache.hadoop.hbase.replication.BaseReplicationEndpoint
-
Returns a WALEntryFilter for checking the scope.
- getScreen() - Method in class org.apache.hadoop.hbase.hbtop.screen.AbstractScreenView
- getSecond() - Method in class org.apache.hadoop.hbase.util.ObjectIntPair
- getSecond() - Method in class org.apache.hadoop.hbase.util.Pair
-
Return the second element stored in the pair.
- getSecond() - Method in class org.apache.hadoop.hbase.util.PairOfSameType
-
Return the second element stored in the pair.
- getSecond() - Method in class org.apache.hadoop.hbase.util.Triple
- getSecondaryAndTertiary(RegionInfo, ServerName) - Method in class org.apache.hadoop.hbase.favored.FavoredNodeAssignmentHelper
- getSecondaryIndexOffsetMarks() - Method in interface org.apache.hadoop.hbase.io.hfile.BlockIndexChunk
- getSecondaryToRegionInfoMap() - Method in class org.apache.hadoop.hbase.master.SnapshotOfRegionAssignmentFromMeta
- getSecondLevelCache() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
- getSecretKeyForSubject(String, Configuration) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
-
Resolves a key for the given subject
- getSecretManager() - Method in class org.apache.hadoop.hbase.ipc.RpcServer
- getSecureBulkLoadManager() - Method in class org.apache.hadoop.hbase.MockRegionServerServices
- getSecureBulkLoadManager() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
- getSecureBulkLoadManager() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
Returns RegionServer's instance of
SecureBulkLoadManager
- getSecurityCapabilities() - Method in interface org.apache.hadoop.hbase.client.Admin
-
Return the set of supported security capabilities.
- getSecurityCapabilities() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Returns the list of supported security capabilities.
- getSecurityCapabilities(RpcController, MasterProtos.SecurityCapabilitiesRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
Returns the security capabilities in effect on the cluster
- getSegments() - Method in class org.apache.hadoop.hbase.regionserver.AbstractMemStore
-
Returns an ordered list of segments from most recent to oldest in memstore
- getSegments() - Method in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
- getSegments() - Method in class org.apache.hadoop.hbase.regionserver.CompactionPipeline
- getSegments() - Method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore
- getSeqNum() - Method in class org.apache.hadoop.hbase.HRegionLocation
- getSeqNumColumn(int) - Static method in class org.apache.hadoop.hbase.CatalogFamilyFormat
-
Returns the column qualifier for seqNum column for replicaId
- getSequenceId() - Method in class org.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValue
- getSequenceId() - Method in class org.apache.hadoop.hbase.ByteBufferKeyValue
- getSequenceId() - Method in interface org.apache.hadoop.hbase.ExtendedCell
-
A region-specific unique monotonically increasing sequence ID given to each Cell.
- getSequenceId() - Method in class org.apache.hadoop.hbase.IndividualBytesFieldCell
- getSequenceId() - Method in class org.apache.hadoop.hbase.KeyValue
-
used to achieve atomic operations in the memstore.
- getSequenceId() - Method in interface org.apache.hadoop.hbase.regionserver.SequenceId
- getSequenceId() - Method in class org.apache.hadoop.hbase.util.MapReduceExtendedCell
- getSequenceId() - Method in class org.apache.hadoop.hbase.wal.WALKeyImpl
-
SequenceId is only available post WAL-assign.
- getSequenceId(Cell) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
- getSequenceID() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileReader
- getSequenceIdAccounting() - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
- getSerializedLength() - Method in interface org.apache.hadoop.hbase.io.hfile.Cacheable
-
Returns the length of the ByteBuffer required to serialized the object.
- getSerializedLength() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
- getSerializedSize() - Method in class org.apache.hadoop.hbase.ByteBufferKeyValue
- getSerializedSize() - Method in interface org.apache.hadoop.hbase.Cell
-
Returns Serialized size (defaults to include tag length if has some tags).
- getSerializedSize() - Method in interface org.apache.hadoop.hbase.ExtendedCell
-
Returns Serialized size (defaults to include tag length).
- getSerializedSize() - Method in class org.apache.hadoop.hbase.KeyValue
- getSerializedSize() - Method in class org.apache.hadoop.hbase.SizeCachedByteBufferKeyValue
-
Override by just returning the length for saving cost of method dispatching.
- getSerializedSize() - Method in class org.apache.hadoop.hbase.SizeCachedKeyValue
-
Override by just returning the length for saving cost of method dispatching.
- getSerializedSize(boolean) - Method in class org.apache.hadoop.hbase.ByteBufferKeyValue
- getSerializedSize(boolean) - Method in interface org.apache.hadoop.hbase.ExtendedCell
-
KeyValue format
- getSerializedSize(boolean) - Method in class org.apache.hadoop.hbase.KeyValue
- getSerializedSize(boolean) - Method in class org.apache.hadoop.hbase.NoTagsByteBufferKeyValue
- getSerializedSize(boolean) - Method in class org.apache.hadoop.hbase.NoTagsKeyValue
- getSerializedSize(boolean) - Method in class org.apache.hadoop.hbase.SizeCachedNoTagsKeyValue
- getSerializedSize(boolean) - Method in class org.apache.hadoop.hbase.util.MapReduceExtendedCell
- getSerializer(Class<Cell>) - Method in class org.apache.hadoop.hbase.mapreduce.CellSerialization
- getSerializer(Class<Mutation>) - Method in class org.apache.hadoop.hbase.mapreduce.MutationSerialization
- getSerializer(Class<Result>) - Method in class org.apache.hadoop.hbase.mapreduce.ResultSerialization
- getSerializer(Class<ExtendedCell>) - Method in class org.apache.hadoop.hbase.mapreduce.ExtendedCellSerialization
- getServer() - Method in class org.apache.hadoop.hbase.HBaseRpcServicesBase
- getServer() - Method in class org.apache.hadoop.hbase.replication.ReplicationEndpoint.Context
- getServerClass() - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord
- getServerColumn(int) - Static method in class org.apache.hadoop.hbase.CatalogFamilyFormat
-
Returns the column qualifier for server column for replicaId
- getServerConnectors() - Method in class org.apache.hadoop.hbase.http.HttpServer
- getServerCrashMetrics() - Method in interface org.apache.hadoop.hbase.master.MetricsMasterSource
-
Returns
OperationMetrics
containing common metrics for server crash operation - getServerCrashMetrics() - Method in class org.apache.hadoop.hbase.master.MetricsMasterSourceImpl
- getServerCrashProcMetrics() - Method in class org.apache.hadoop.hbase.master.MetricsMaster
-
Returns Set of metrics for assign procedure
- getServerHoldingMeta() - Method in class org.apache.hadoop.hbase.HBaseCluster
-
Deprecated.Get the ServerName of region server serving the first hbase:meta region
- getServerHoldingRegion(TableName, byte[]) - Method in class org.apache.hadoop.hbase.HBaseCluster
-
Deprecated.Get the ServerName of region server serving the specified region
- getServerHoldingRegion(TableName, byte[]) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.
- getServerImpl(Configuration) - Static method in enum class org.apache.hadoop.hbase.thrift.ImplType
- getServerInfo(AdminProtos.GetServerInfoRequest) - Method in class org.apache.hadoop.hbase.client.AsyncRegionServerAdmin
- getServerInfo(RpcController, AdminProtos.AdminService.BlockingInterface) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
A helper to get the info of a region server using admin protocol.
- getServerInfo(RpcController, AdminProtos.GetServerInfoRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- getServerInfo(RpcController, AdminProtos.GetServerInfoRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
Get some information of the region server.
- getServerManager() - Method in class org.apache.hadoop.hbase.master.HMaster
- getServerManager() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Returns Master's
ServerManager
instance. - getServerName() - Method in class org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination.SplitLogManagerDetails
-
Deprecated.Returns server name
- getServerName() - Method in interface org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment
-
Returns Hosting Server's ServerName
- getServerName() - Method in interface org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment
-
Returns Hosting Server's ServerName
- getServerName() - Method in interface org.apache.hadoop.hbase.coprocessor.RegionServerCoprocessorEnvironment
-
Returns Hosting Server's ServerName
- getServerName() - Method in exception org.apache.hadoop.hbase.exceptions.RegionMovedException
- getServerName() - Method in class org.apache.hadoop.hbase.HBaseServerBase
- getServerName() - Method in class org.apache.hadoop.hbase.HbckUnknownServers
- getServerName() - Method in class org.apache.hadoop.hbase.HRegionLocation
- getServerName() - Method in class org.apache.hadoop.hbase.http.HttpServer.QuotingInputFilter.RequestQuoter
-
Quote the server name so that users specifying the HOST HTTP header can't inject attacks.
- getServerName() - Method in class org.apache.hadoop.hbase.master.HMaster
- getServerName() - Method in interface org.apache.hadoop.hbase.master.MetricsMasterWrapper
-
Get ServerName
- getServerName() - Method in class org.apache.hadoop.hbase.master.MetricsMasterWrapperImpl
- getServerName() - Method in class org.apache.hadoop.hbase.master.RegionState
- getServerName() - Method in class org.apache.hadoop.hbase.MockRegionServerServices
- getServerName() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get ServerName
- getServerName() - Method in class org.apache.hadoop.hbase.replication.ReplicationQueueId
- getServerName() - Method in class org.apache.hadoop.hbase.rest.RESTServer
- getServerName() - Method in interface org.apache.hadoop.hbase.Server
-
Returns The unique server name for this server.
- getServerName() - Method in interface org.apache.hadoop.hbase.ServerMetrics
- getServerName() - Method in class org.apache.hadoop.hbase.ServerName
- getServerName() - Method in class org.apache.hadoop.hbase.SplitLogTask
-
Deprecated.
- getServerName(Result, int) - Static method in class org.apache.hadoop.hbase.CatalogFamilyFormat
-
Returns a
ServerName
from catalog tableResult
. - getServerNameColumn(int) - Static method in class org.apache.hadoop.hbase.CatalogFamilyFormat
-
Returns the column qualifier for serialized region state
- getServerNameFromWALDirectoryName(Configuration, String) - Static method in class org.apache.hadoop.hbase.wal.AbstractFSWALProvider
-
Pulls a ServerName out of a Path generated according to our layout rules.
- getServerNameFromWALDirectoryName(Path) - Static method in class org.apache.hadoop.hbase.wal.AbstractFSWALProvider
-
This function returns region server name from a log file name which is in one of the following formats: hdfs://<name node>/hbase/.logs/<server name>-splitting/... hdfs://<name node>/hbase/.logs/<server name>/...
- getServerNameInMeta() - Method in class org.apache.hadoop.hbase.HbckInconsistentRegions
- getServerNamesFromWALDirPath(PathFilter) - Method in class org.apache.hadoop.hbase.master.MasterWalManager
-
Returns listing of ServerNames found by parsing WAL directory paths in FS.
- getServerPrincipal() - Method in class org.apache.hadoop.hbase.security.SecurityInfo
-
Deprecated.Since 2.6.0, will be removed in 4.0.0. Use
SecurityInfo.getServerPrincipals()
instead. - getServerPrincipals() - Method in class org.apache.hadoop.hbase.security.SecurityInfo
- getServers() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.Summary
- getServers() - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
-
Get list of servers.
- getServersName() - Method in interface org.apache.hadoop.hbase.ClusterMetrics
- getServerStats() - Method in class org.apache.hadoop.hbase.client.MetricsConnection
-
serverStats metric
- getServerTask(ClusterStatusProtos.ServerTask) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
- getServerWALsBelongTo() - Method in class org.apache.hadoop.hbase.replication.ReplicationQueueId
- getServerWith(byte[]) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.Get the location of the specified region
- getServerWithMeta() - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.
- getService() - Method in interface org.apache.hadoop.hbase.coprocessor.CoprocessorService
-
Deprecated.
- getService() - Method in interface org.apache.hadoop.hbase.ipc.RpcCall
-
Returns The service of this call.
- getService() - Method in class org.apache.hadoop.hbase.ipc.ServerCall
- getService(List<RpcServer.BlockingServiceAndInterface>, String) - Static method in class org.apache.hadoop.hbase.ipc.RpcServer
- getServiceAndInterface(List<RpcServer.BlockingServiceAndInterface>, String) - Static method in class org.apache.hadoop.hbase.ipc.RpcServer
- getServiceInterface() - Method in class org.apache.hadoop.hbase.ipc.RpcServer.BlockingServiceAndInterface
- getServiceInterface(List<RpcServer.BlockingServiceAndInterface>, String) - Static method in class org.apache.hadoop.hbase.ipc.RpcServer
- getServiceName(Descriptors.ServiceDescriptor) - Static method in class org.apache.hadoop.hbase.ipc.CoprocessorRpcUtils
-
Returns the name to use for coprocessor service calls.
- getServices() - Method in interface org.apache.hadoop.hbase.Coprocessor
-
Coprocessor endpoints providing protobuf services should override this method.
- getServices() - Method in class org.apache.hadoop.hbase.coprocessor.MultiRowMutationEndpoint
- getServices() - Method in class org.apache.hadoop.hbase.HBaseRpcServicesBase
- getServices() - Method in class org.apache.hadoop.hbase.ipc.RpcServer
- getServices() - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
Returns list of blocking services and their security info classes that this server supports
- getServices() - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
By default, put up an Admin and a Client Service.
- getServices() - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
-
Deprecated.
- getServices() - Method in class org.apache.hadoop.hbase.security.HBasePolicyProvider
- getSessionId() - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
- getSettingsQualifierForUserNamespace(String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
- getSettingsQualifierForUserTable(TableName) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
- getSettingsQualifierRegexForUserNamespace(String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
- getSettingsQualifierRegexForUserTable(String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
- getSeverity() - Method in class org.apache.hadoop.hbase.tool.coprocessor.CoprocessorViolation
- getSharedData() - Method in interface org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment
-
Returns shared data between all instances of this coprocessor
- getSharedStoreFilePercentage() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
-
Returns the percentage of the shared store files
- getSharedStoreFilesSize() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
-
Returns the total size of the store files shared
- getShort() - Method in class org.apache.hadoop.hbase.nio.ByteBuff
-
Returns the short value at the current position.
- getShort() - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
Returns the short value at the current position.
- getShort() - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
- getShort() - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
- getShort() - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
Retrieve the next short value from this range.
- getShort(int) - Method in class org.apache.hadoop.hbase.nio.ByteBuff
-
Fetches the short value at the given index.
- getShort(int) - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
Fetches the short at the given index.
- getShort(int) - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
- getShort(int) - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
- getShort(int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Retrieve the short value at
index
- getShortAfterPosition(int) - Method in class org.apache.hadoop.hbase.nio.ByteBuff
-
Fetches the short value at the given offset from current position.
- getShortAfterPosition(int) - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
- getShortAfterPosition(int) - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
- getShortCircuitBytesRead() - Static method in class org.apache.hadoop.hbase.io.FSDataInputStreamWrapper
- getShortCircuitBytesRead() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Returns Number of bytes read locally through HDFS short circuit.
- getShortDescription() - Method in class org.apache.hadoop.hbase.backup.BackupInfo
- getShortHistogramReport(Histogram) - Static method in class org.apache.hadoop.hbase.util.YammerHistogramUtils
-
Returns an abbreviated summary of
hist
. - getShortName() - Method in class org.apache.hadoop.hbase.security.User
-
Returns the shortened version of the user name -- the portion that maps to an operating system user name.
- getShortName() - Method in class org.apache.hadoop.hbase.security.User.SecureHadoopUser
- getShortNameToLog() - Method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Returns Return a short, printable name for this region (usually encoded name) for us logging.
- getShortNameToLog(List<RegionInfo>) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Returns a String of short, printable names for
hris
(usually encoded name) for us logging. - getShortNameToLog(RegionInfo...) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Returns a String of short, printable names for
hris
(usually encoded name) for us logging. - getShortTextFormat(Message) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Return short version of Message toString'd, shorter than TextFormat#shortDebugString.
- getSimpleComparator() - Method in interface org.apache.hadoop.hbase.CellComparator
-
Return a dumbed-down, fast comparator for hbase2 base-type, the
ByteBufferKeyValue
. - getSimpleComparator() - Method in class org.apache.hadoop.hbase.CellComparatorImpl
- getSimpleComparator() - Method in class org.apache.hadoop.hbase.MetaCellComparator
- getSimpleName() - Method in enum class org.apache.hadoop.hbase.Size.Unit
- getSize() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.batch.BatchTerminal
- getSize() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.TerminalImpl
- getSize() - Method in interface org.apache.hadoop.hbase.hbtop.terminal.Terminal
- getSize() - Method in class org.apache.hadoop.hbase.io.encoding.EncodedDataBlock
-
Find the size of minimal buffer that could store compressed data.
- getSize() - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil.CachedBlocksByFile
-
Returns size of blocks in the cache
- getSize() - Method in interface org.apache.hadoop.hbase.io.hfile.CachedBlock
- getSize() - Method in interface org.apache.hadoop.hbase.ipc.RpcCall
-
Used to calculate the request call queue size.
- getSize() - Method in class org.apache.hadoop.hbase.ipc.ServerCall
- getSize() - Method in interface org.apache.hadoop.hbase.quotas.RegionSize
-
Returns the size of the region.
- getSize() - Method in class org.apache.hadoop.hbase.quotas.RegionSizeImpl
- getSize() - Method in class org.apache.hadoop.hbase.regionserver.HStore
- getSize() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Returns aggregate size of HStore
- getSize() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
Size of the Hfile
- getSize() - Method in class org.apache.hadoop.hbase.replication.ReplicationEndpoint.ReplicateContext
- getSizeOfLogQueue() - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSource
- getSizeToCheck(int) - Method in class org.apache.hadoop.hbase.regionserver.IncreasingToUpperBoundRegionSplitPolicy
- getSizeToCheck(int) - Method in class org.apache.hadoop.hbase.regionserver.SteppingSplitPolicy
- getSkipBadLines() - Method in class org.apache.hadoop.hbase.mapreduce.TextSortReducer
- getSkipBadLines() - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
- getSkipBadLines() - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterTextMapper
- getSkippingRow() - Method in class org.apache.hadoop.hbase.regionserver.ScannerContext
-
In this mode, only block size progress is tracked, and limits are ignored.
- getSleepInterval() - Method in class org.apache.hadoop.hbase.util.RetryCounter.RetryConfig
- getSlowAppendCount() - Method in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
- getSlowAppendCount() - Method in class org.apache.hadoop.hbase.regionserver.wal.MetricsWALSourceImpl
- getSlowLogParams(Message, boolean) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Return SlowLogParams to maintain recent online slowlog responses
- getSlowLogPayloads() - Method in class org.apache.hadoop.hbase.namequeues.response.NamedQueueGetResponse
- getSlowLogResponseRequest() - Method in class org.apache.hadoop.hbase.namequeues.request.NamedQueueGetRequest
- getSlowLogResponses(Set<ServerName>, LogQueryFilter) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Deprecated.since 2.4.0 and will be removed in 4.0.0. Use
Admin.getLogEntries(Set, String, ServerType, int, Map)
instead. - getSlowLogResponses(Set<ServerName>, LogQueryFilter) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Deprecated.since 2.4.0 and will be removed in 4.0.0. Use
AsyncAdmin.getLogEntries(Set, String, ServerType, int, Map)
instead. - getSmallCompactionQueueSize() - Method in class org.apache.hadoop.hbase.regionserver.CompactSplit
- getSmallCompactionQueueSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
- getSmallCompactionThreadNum() - Method in class org.apache.hadoop.hbase.regionserver.CompactSplit
- getSmallestReadPoint() - Method in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
- getSmallestReadPoint() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
- getSmallestReadPoint() - Method in class org.apache.hadoop.hbase.regionserver.HStore
- getSmallestReadPoint() - Method in interface org.apache.hadoop.hbase.regionserver.Store
- getSnapshot() - Method in interface org.apache.hadoop.hbase.master.SnapshotSentinel
-
Returns the description of the snapshot being run
- getSnapshotDescription() - Method in exception org.apache.hadoop.hbase.snapshot.HBaseSnapshotException
-
Returns the description of the snapshot that is being failed
- getSnapshotDescription() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
-
Returns the snapshot descriptor
- getSnapshotDescription() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotManifest
-
Get the SnapshotDescription
- getSnapshotDir() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotManifest
-
Get the current snapshot working dir
- getSnapshotDirs(Configuration) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableSnapshotInputFormatImpl
-
Retrieve the directories into which snapshots have been restored from (
MultiTableSnapshotInputFormatImpl.RESTORE_DIRS_KEY
) - getSnapshotList(Configuration) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo
-
Returns the list of available snapshots in the specified location
- getSnapshotManager() - Method in class org.apache.hadoop.hbase.master.HMaster
-
Returns the underlying snapshot manager
- getSnapshotManager() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Returns the underlying snapshot manager
- getSnapshotManifest(Configuration, String, Path, FileSystem) - Static method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl
- getSnapshotName() - Method in class org.apache.hadoop.hbase.backup.BackupTableInfo
- getSnapshotName(TableName) - Method in class org.apache.hadoop.hbase.backup.BackupInfo
- getSnapshotNames() - Method in class org.apache.hadoop.hbase.backup.BackupInfo
- getSnapshotQuotaObserverChore() - Method in class org.apache.hadoop.hbase.master.HMaster
- getSnapshotRootDir(Path) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
Get the snapshot root directory.
- getSnapshots(Connection) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
Fetches all
SpaceQuotaSnapshot
objects from thehbase:quota
table. - getSnapshotsDir(Path) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
- getSnapshotSegments() - Method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore
- getSnapshotsFilesMap(Configuration, AtomicLong, AtomicLong, AtomicLong) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo
-
Returns the map of store files based on path for all snapshots
- getSnapshotSize() - Method in class org.apache.hadoop.hbase.regionserver.AbstractMemStore
- getSnapshotSize() - Method in class org.apache.hadoop.hbase.regionserver.HStore
- getSnapshotSize() - Method in interface org.apache.hadoop.hbase.regionserver.MemStore
-
Return the size of the snapshot(s) if any
- getSnapshotSize() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Returns size of the memstore snapshot
- getSnapshotSizeQualifier(String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
- getSnapshotStats(Configuration, SnapshotDescription) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo
-
Returns the snapshot stats
- getSnapshotStats(Configuration, SnapshotProtos.SnapshotDescription, Map<Path, Integer>) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo
-
Returns the snapshot stats
- getSnapshotsToScans(Configuration) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableSnapshotInputFormatImpl
-
Retrieve the snapshot name -> list<scan> mapping pushed to configuration by
MultiTableSnapshotInputFormatImpl.setSnapshotToScans(Configuration, Map)
- getSocketAddr(String, String, int) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
- getSocketAddr(String, String, String, int) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
- getSocketAddress() - Method in class org.apache.hadoop.hbase.HBaseRpcServicesBase
- getSoftLimit() - Method in class org.apache.hadoop.hbase.quotas.ThrottleSettings
- getSource() - Method in exception org.apache.hadoop.hbase.errorhandling.ForeignException
- getSource() - Method in class org.apache.hadoop.hbase.master.RegionPlan
-
Get the source server for the plan for this region.
- getSource() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsUserAggregate
-
Returns return a singleton instance of MetricsUserAggregateSource or null in case of NoOp
- getSource() - Method in class org.apache.hadoop.hbase.regionserver.MetricsUserAggregateImpl
- getSource() - Method in class org.apache.hadoop.hbase.rest.MetricsREST
- getSource() - Method in class org.apache.hadoop.hbase.thrift.ThriftMetrics
- getSourceName() - Method in exception org.apache.hadoop.hbase.errorhandling.TimeoutException
- getSourceServerName() - Method in class org.apache.hadoop.hbase.replication.ReplicationQueueId
- getSpaceProto() - Method in class org.apache.hadoop.hbase.quotas.GlobalQuotaSettingsImpl
- getSpaceQuota(String) - Method in class org.apache.hadoop.hbase.quotas.NamespaceQuotaSnapshotStore
- getSpaceQuota(TableName) - Method in class org.apache.hadoop.hbase.quotas.TableQuotaSnapshotStore
- getSpaceQuota(T) - Method in interface org.apache.hadoop.hbase.quotas.QuotaSnapshotStore
-
Fetch the Quota for the given
subject
. - getSpaceQuotaRegionSizes(RpcController, QuotaProtos.GetSpaceQuotaRegionSizesRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- getSpaceQuotaSnapshotNotifier() - Method in class org.apache.hadoop.hbase.master.HMaster
- getSpaceQuotaSnapshots(QuotaProtos.GetSpaceQuotaSnapshotsRequest) - Method in class org.apache.hadoop.hbase.client.AsyncRegionServerAdmin
- getSpaceQuotaSnapshots(RpcController, QuotaProtos.GetSpaceQuotaSnapshotsRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- getSpaceQuotaSnapshots(RpcController, QuotaProtos.GetSpaceQuotaSnapshotsRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
- getSpaceQuotaTableSizes() - Method in interface org.apache.hadoop.hbase.client.Admin
-
Fetches the table sizes on the filesystem as tracked by the HBase Master.
- getSpaceQuotaTableSizes() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Fetches the table sizes on the filesystem as tracked by the HBase Master.
- getSplitAlgo(Configuration) - Static method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl
- getSplitCount() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreConfig
- getSplitEditFilesSorted(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.wal.WALSplitUtil
-
Returns sorted set of edit files made by splitter, excluding files with '.temp' suffix.
- getSplitKey() - Method in class org.apache.hadoop.hbase.io.Reference
- getSplitKeysArray(MasterProtos.CreateTableRequest) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
get the split keys in form "byte [][]" from a CreateTableRequest proto
- getSplitLogDir(Path, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog
-
Deprecated.
- getSplitLogManagerCoordination() - Method in interface org.apache.hadoop.hbase.CoordinatedStateManager
-
Method to retrieve coordination for split log manager
- getSplitLogManagerCoordination() - Method in class org.apache.hadoop.hbase.coordination.ZkCoordinatedStateManager
-
Deprecated.
- getSplitLogWorkerCoordination() - Method in interface org.apache.hadoop.hbase.CoordinatedStateManager
-
Method to retrieve coordination for split log worker
- getSplitLogWorkerCoordination() - Method in class org.apache.hadoop.hbase.coordination.ZkCoordinatedStateManager
-
Deprecated.
- getSplitMetrics() - Method in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
-
Returns
OperationMetrics
containing common metrics for split operation - getSplitMetrics() - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManagerSourceImpl
- getSplitOrMergeStateStore() - Method in class org.apache.hadoop.hbase.master.HMaster
- getSplitPartSize() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreConfig
- getSplitPlanCount() - Method in interface org.apache.hadoop.hbase.master.MetricsMasterWrapper
-
Get the number of region split plans executed.
- getSplitPlanCount() - Method in class org.apache.hadoop.hbase.master.MetricsMasterWrapperImpl
- getSplitPoint() - Method in class org.apache.hadoop.hbase.regionserver.DelimitedKeyPrefixRegionSplitPolicy
-
Deprecated.
- getSplitPoint() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
Determines if Store should be split.
- getSplitPoint() - Method in class org.apache.hadoop.hbase.regionserver.KeyPrefixRegionSplitPolicy
-
Deprecated.
- getSplitPoint() - Method in class org.apache.hadoop.hbase.regionserver.RegionSplitPolicy
- getSplitPoint() - Method in interface org.apache.hadoop.hbase.regionserver.StoreFileManager
-
Gets the split point for the split of this set of store files (approx.
- getSplitPoint() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
-
Override of getSplitPoint that determines the split point as the boundary between two stripes, unless it causes significant imbalance between split sides' sizes.
- getSplitPolicyClass(TableDescriptor, Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.RegionSplitPolicy
- getSplitProcMetrics() - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManager
-
Returns Set of common metrics for split procedure
- getSplitQueueSize() - Method in class org.apache.hadoop.hbase.regionserver.CompactSplit
- getSplitQueueSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the size of the split queue
- getSplitRegions() - Method in class org.apache.hadoop.hbase.client.RegionStatesCount
- getSplits() - Method in class org.apache.hadoop.hbase.util.RegionSplitCalculator
- getSplits(Configuration) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableSnapshotInputFormatImpl
-
Return the list of splits extracted from the scans/snapshots pushed to conf by
MultiTableSnapshotInputFormatImpl.setInput(Configuration, Map, Path)
- getSplits(Configuration) - Static method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl
- getSplits(Scan, SnapshotManifest, List<RegionInfo>, Path, Configuration) - Static method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl
- getSplits(Scan, SnapshotManifest, List<RegionInfo>, Path, Configuration, RegionSplitter.SplitAlgorithm, int) - Static method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl
- getSplits(PerformanceEvaluation.TestOptions) - Static method in class org.apache.hadoop.hbase.PerformanceEvaluation
-
generates splits based on total number of rows and specified split regions
- getSplits(JobConf, int) - Method in class org.apache.hadoop.hbase.mapred.MultiTableSnapshotInputFormat
- getSplits(JobConf, int) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
-
Calculates the splits that will serve as input for the map tasks.
- getSplits(JobConf, int) - Method in class org.apache.hadoop.hbase.mapred.TableSnapshotInputFormat
- getSplits(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableInputFormatBase
-
Calculates the splits that will serve as input for the map tasks.
- getSplits(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableSnapshotInputFormat
- getSplits(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.RoundRobinTableInputFormat
- getSplits(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
Calculates the splits that will serve as input for the map tasks.
- getSplits(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
Calculates the splits that will serve as input for the map tasks.
- getSplits(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormat
- getSplits(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.WALInputFormat
- getSplitsDir(RegionInfo) - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
- getSplitSize() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreConfig
- getSplittableRegion(TableName, int) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Retrieves a splittable region randomly from tableName
- getSplitThreadNum() - Method in class org.apache.hadoop.hbase.regionserver.CompactSplit
- getSplittingServersFromWALDir() - Method in class org.apache.hadoop.hbase.master.MasterWalManager
-
Get Servernames which are currently splitting; paths have a '-splitting' suffix.
- getSplitWALManager() - Method in class org.apache.hadoop.hbase.master.HMaster
- getSplitWALManager() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Returns return null if current is zk-based WAL splitting
- getSrcChecksum() - Static method in class org.apache.hadoop.hbase.util.VersionInfo
-
Get the checksum of the source files from which Hadoop was compiled.
- getStagingDir(Configuration) - Static method in class org.apache.hadoop.hbase.mapreduce.JobUtil
-
Initializes the staging directory and returns the path.
- getStamp() - Method in class org.apache.hadoop.hbase.master.RegionState
- getStart() - Method in exception org.apache.hadoop.hbase.errorhandling.TimeoutException
- getStartcode() - Method in class org.apache.hadoop.hbase.HBaseServerBase
-
Returns time stamp in millis of when this server was started
- getStartcode() - Method in class org.apache.hadoop.hbase.ServerName
-
Deprecated.Since 2.5.0, will be removed in 4.0.0. Use
ServerName.getStartCode()
instead. - getStartCode() - Method in class org.apache.hadoop.hbase.HbckServerName
- getStartCode() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get HRegionServer start time
- getStartCode() - Method in class org.apache.hadoop.hbase.ServerName
-
Return the start code.
- getStartCodeColumn(int) - Static method in class org.apache.hadoop.hbase.CatalogFamilyFormat
-
Returns the column qualifier for server start code column for replicaId
- getStartEndKeys() - Method in interface org.apache.hadoop.hbase.client.AsyncTableRegionLocator
-
Gets the starting and ending row keys for every region in the currently open table.
- getStartEndKeys() - Method in interface org.apache.hadoop.hbase.client.RegionLocator
-
Gets the starting and ending row keys for every region in the currently open table.
- getStartEndKeys() - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
- getStartEndKeys() - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
- getStartKey() - Method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Returns the startKey.
- getStartKey() - Method in class org.apache.hadoop.hbase.HbckRegionDetails
- getStartKey() - Method in class org.apache.hadoop.hbase.mob.MobFileName
-
Gets the hex string of the md5 for a start key.
- getStartKey() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher
-
Returns the start key
- getStartKey() - Method in class org.apache.hadoop.hbase.util.HbckRegionInfo
- getStartKey() - Method in interface org.apache.hadoop.hbase.util.KeyRange
- getStartKey(byte[]) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Gets the start key from the specified region name.
- getStartKeyForDisplay(RegionInfo, Configuration) - Static method in class org.apache.hadoop.hbase.client.RegionInfoDisplay
-
Get the start key for display.
- getStartKeyFromName(String) - Static method in class org.apache.hadoop.hbase.mob.MobFileName
-
get startKey from MobFileName.
- getStartKeys() - Method in interface org.apache.hadoop.hbase.client.AsyncTableRegionLocator
-
Gets the starting row key for every region in the currently open table.
- getStartKeys() - Method in interface org.apache.hadoop.hbase.client.RegionLocator
-
Gets the starting row key for every region in the currently open table.
- getStartRow() - Method in class org.apache.hadoop.hbase.client.ImmutableScan
- getStartRow() - Method in class org.apache.hadoop.hbase.client.Scan
-
Returns the startrow
- getStartRow() - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.RowRange
- getStartRow() - Method in class org.apache.hadoop.hbase.mapred.TableSplit
-
Returns starting row key
- getStartRow() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
-
Returns the start row.
- getStartRow() - Method in class org.apache.hadoop.hbase.rest.RowSpec
- getStartRow(int) - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
- getStarts() - Method in class org.apache.hadoop.hbase.util.RegionSplitCalculator
- getStartTime() - Method in class org.apache.hadoop.hbase.client.MetricsConnection.CallStats
- getStartTime() - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord
- getStartTime() - Method in interface org.apache.hadoop.hbase.ipc.RpcCall
-
Returns The time when the call starts to be executed.
- getStartTime() - Method in class org.apache.hadoop.hbase.ipc.ServerCall
- getStartTime() - Method in interface org.apache.hadoop.hbase.master.MetricsMasterWrapper
-
Get hbase master start time
- getStartTime() - Method in class org.apache.hadoop.hbase.master.MetricsMasterWrapperImpl
- getStartTime() - Method in class org.apache.hadoop.hbase.rest.RowSpec
- getStartTime() - Method in interface org.apache.hadoop.hbase.ServerTask
-
Get the task start time.
- getStartTs() - Method in class org.apache.hadoop.hbase.backup.BackupInfo
- getStartupProgress() - Method in class org.apache.hadoop.hbase.master.HMaster
- getState() - Method in class org.apache.hadoop.hbase.backup.BackupInfo
- getState() - Method in class org.apache.hadoop.hbase.client.TableState
-
Returns table state
- getState() - Method in class org.apache.hadoop.hbase.io.FileChangeWatcher
-
Returns the current
FileChangeWatcher.State
. - getState() - Method in class org.apache.hadoop.hbase.master.MasterStateStore
- getState() - Method in class org.apache.hadoop.hbase.master.RegionState
- getState() - Method in class org.apache.hadoop.hbase.namequeues.WALEventTrackerPayload
- getState() - Method in class org.apache.hadoop.hbase.replication.ReplicationBarrierFamilyFormat.ReplicationBarrierResult
- getState() - Method in interface org.apache.hadoop.hbase.ServerTask
-
Get the current state of the task.
- getState() - Method in class org.apache.hadoop.hbase.wal.WALTailingReader.Result
- getState() - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
- getState(int) - Method in class org.apache.hadoop.hbase.regionserver.storefiletracker.ModifyStoreFileTrackerProcedure
- getState(String) - Method in class org.apache.hadoop.hbase.namespace.NamespaceAuditor
- getStateId(MasterProcedureProtos.ModifyStoreFileTrackerState) - Method in class org.apache.hadoop.hbase.regionserver.storefiletracker.ModifyStoreFileTrackerProcedure
- getStaticBloomSize(String) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregate
-
Returns the size of the static blooms for this table
- getStaticBloomSize(String) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImpl
- getStaticIndexSize(String) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregate
-
Returns the size of the static indexes for this table
- getStaticIndexSize(String) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImpl
- getStatisticsAtIndex(int) - Method in class org.apache.hadoop.hbase.util.WindowMovingAverage
-
Get statistics at index.
- getStats() - Method in class org.apache.hadoop.hbase.client.Result
-
Returns the associated statistics about the region from which this was returned.
- getStats() - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCache
-
Get the statistics for this block cache.
- getStats() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
- getStats() - Method in class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache
-
Get counter statistics for this cache.
- getStats() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
Get counter statistics for this cache.
- getStats() - Method in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
- getStats() - Method in class org.apache.hadoop.hbase.io.hfile.TinyLfuBlockCache
- getStats(ServerName) - Method in class org.apache.hadoop.hbase.client.ServerStatisticTracker
- getStatsForRegion(byte[]) - Method in class org.apache.hadoop.hbase.client.backoff.ServerStatistics
- getStatus() - Static method in class org.apache.hadoop.hbase.ipc.RpcServer
- getStatus() - Method in interface org.apache.hadoop.hbase.ServerTask
-
Get the current status of the task.
- getStatusAndProgressAsString() - Method in class org.apache.hadoop.hbase.backup.BackupInfo
- getStealFromQueue() - Method in class org.apache.hadoop.hbase.util.StealJobQueue
-
Get a queue whose job might be stolen by the consumer of this original queue
- getStopper() - Method in class org.apache.hadoop.hbase.ScheduledChore
- getStopRow() - Method in class org.apache.hadoop.hbase.client.ImmutableScan
- getStopRow() - Method in class org.apache.hadoop.hbase.client.Scan
-
Returns the stoprow
- getStopRow() - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.RowRange
- getStopRowKey() - Method in class org.apache.hadoop.hbase.filter.InclusiveStopFilter
- getStoragePolicy() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Not using
enum
here because HDFS is not usingenum
for storage policy, see org.apache.hadoop.hdfs.server.blockmanagement.BlockStoragePolicySuite for more details. - getStoragePolicyName(String) - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
Get the storage policy of the directory of CF.
- getStore() - Method in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
- getStore(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
- getStore(byte[]) - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Return the Store for the given family
- getStoreArchivePath(Configuration, RegionInfo, byte[]) - Static method in class org.apache.hadoop.hbase.util.HFileArchiveUtil
-
Gets the directory to archive a store directory.
- getStoreArchivePath(Configuration, RegionInfo, Path, byte[]) - Static method in class org.apache.hadoop.hbase.util.HFileArchiveUtil
-
Get the directory to archive a store directory
- getStoreArchivePath(Configuration, TableName, String, String) - Static method in class org.apache.hadoop.hbase.util.HFileArchiveUtil
-
Get the directory to archive a store directory
- getStoreArchivePathForArchivePath(Path, RegionInfo, byte[]) - Static method in class org.apache.hadoop.hbase.util.HFileArchiveUtil
- getStoreArchivePathForRootDir(Path, RegionInfo, byte[]) - Static method in class org.apache.hadoop.hbase.util.HFileArchiveUtil
-
Gets the archive directory under specified root dir.
- getStoreCompactionPriority() - Method in interface org.apache.hadoop.hbase.regionserver.StoreFileManager
-
Returns The store compaction priority.
- getStoreCompactionPriority() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
- getStoreContext() - Method in class org.apache.hadoop.hbase.regionserver.HStore
- getStoreCount() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
Returns the number of stores
- getStoreDir(String) - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
Returns the directory path of the specified family
- getStoreEngine() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
Returns the StoreEngine that is backing this concrete implementation of Store.
- getStoreFile(AdminProtos.GetStoreFileRequest) - Method in class org.apache.hadoop.hbase.client.AsyncRegionServerAdmin
- getStoreFile(RpcController, AdminProtos.GetStoreFileRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- getStoreFile(RpcController, AdminProtos.GetStoreFileRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
- getStoreFileComparator() - Method in interface org.apache.hadoop.hbase.regionserver.StoreFileManager
- getStoreFileComparator() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
- getStorefileCount() - Method in interface org.apache.hadoop.hbase.regionserver.StoreFileManager
-
Returns the number of files currently in use.
- getStorefileCount() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
- getStoreFileCount() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
Returns the number of storefiles
- getStorefileFieldSize(HStoreFile, ToLongFunction<StoreFileReader>) - Static method in class org.apache.hadoop.hbase.regionserver.StoreUtils
- getStoreFileIndexSize() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
TODO: why we pass the same value to different counters? Currently, the value from getStoreFileIndexSize() is same with getStoreFileRootLevelIndexSize() see HRegionServer#createRegionLoad.
- getStoreFileIndexSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the Size (in bytes) of indexes in storefiles on disk.
- getStoreFileInfo(Configuration, FileSystem, RegionInfo, RegionInfo, String, Path, StoreFileTracker) - Static method in class org.apache.hadoop.hbase.util.ServerRegionReplicaUtil
-
Returns a StoreFileInfo from the given FileStatus.
- getStoreFileInfo(FileStatus, Path, boolean) - Method in interface org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileTracker
- getStoreFileInfo(Path, boolean) - Method in interface org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileTracker
- getStoreFileList(byte[][]) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
- getStoreFileList(byte[][]) - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Returns list of store file names for the given families
- getStoreFileManager() - Method in class org.apache.hadoop.hbase.regionserver.StoreEngine
-
Returns Store file manager to use.
- getStoreFileRootLevelIndexSize() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
Returns The current total size of root-level indexes for the region
- getStorefiles() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
Returns All store files.
- getStorefiles() - Method in interface org.apache.hadoop.hbase.regionserver.Store
- getStoreFiles() - Method in interface org.apache.hadoop.hbase.regionserver.StoreFileManager
-
Gets the snapshot of the store files currently in use.
- getStoreFiles() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
- getStoreFiles(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
-
Returns all HFiles belonging to the given region directory.
- getStoreFiles(StoreFileTracker, HRegionFileSystem, String, boolean) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotManifestV1
- getStoreFiles(AdminProtos.AdminService.BlockingInterface, byte[], byte[]) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
A helper to get the list of files of a column family on a given region using admin protocol.
- getStoreFiles(RpcController, AdminProtos.AdminService.BlockingInterface, byte[], byte[]) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
A helper to get the list of files of a column family on a given region using admin protocol.
- getStoreFilesBeingWritten() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
Return the storefiles which are currently being written to.
- getStoreFileScanner(boolean, boolean, boolean, long, long, boolean) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileReader
-
Get a scanner to scan over this StoreFile.
- getStorefilesCount() - Method in class org.apache.hadoop.hbase.regionserver.HStore
- getStorefilesCount() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Returns Count of store files
- getStoreFilesCount() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
-
Returns the number of available store files
- getStoreFileSize() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
Returns the total size of the storefiles
- getStoreFileSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the total size of the store files this region server is serving from.
- getStoreFileSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
-
Get the total size of the store files this region server is serving from.
- getStoreFileSize() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
- getStoreFileSize(String) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregate
-
Get the store file size against this table
- getStoreFileSize(String) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImpl
- getStoreFileSizeGrowthRate() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the growth rate of the store files this region server is serving from.
- getStoreFilesLocatedStatus(HRegionFileSystem, String, boolean) - Static method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
Returns the store files' LocatedFileStatus which available for the family.
- getStorefilesRootLevelIndexSize() - Method in class org.apache.hadoop.hbase.regionserver.HStore
- getStorefilesRootLevelIndexSize() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Returns The size of the store file root-level indexes, in bytes.
- getStorefilesSize() - Method in class org.apache.hadoop.hbase.regionserver.HStore
- getStorefilesSize() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Returns The size of the store files, in bytes.
- getStorefilesSize(Collection<HStoreFile>, Predicate<HStoreFile>) - Static method in class org.apache.hadoop.hbase.regionserver.StoreUtils
- getStoreFilesSize() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
-
Returns the total size of the store files referenced by the snapshot
- getStoreFileTracker(String, HRegionFileSystem) - Method in class org.apache.hadoop.hbase.util.compaction.MajorCompactionTTLRequest
- getStoreFileTrackerName(Class<? extends StoreFileTracker>) - Static method in class org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileTrackerFactory
- getStoreFileTrackerName(Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileTrackerFactory
- getStoreFileTtl() - Method in class org.apache.hadoop.hbase.regionserver.HStore
- getStoreFileTtl() - Method in interface org.apache.hadoop.hbase.regionserver.StoreConfigInformation
-
Returns Gets the cf-specific time-to-live for store files.
- getStoreFileUncompressedDataIndexSize() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
Returns The total size of all index blocks, not just the root level
- getStoreFlusher() - Method in class org.apache.hadoop.hbase.regionserver.StoreEngine
-
Returns Store flusher to use.
- getStoreHomedir(Path, String, byte[]) - Static method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
- getStoreHomedir(Path, RegionInfo, byte[]) - Static method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
- getStoreInfo() - Method in class org.apache.hadoop.hbase.mob.DefaultMobStoreCompactor
- getStoreRefCount() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
Returns the reference count for the stores of this region
- getStoreRefCount() - Method in class org.apache.hadoop.hbase.regionserver.HStore
- getStoreRefCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
-
Returns the number of references active on the store
- getStoreRefCount() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
- getStores() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
- getStores() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Return the list of Stores managed by this region
- getStoreSegments() - Method in class org.apache.hadoop.hbase.regionserver.VersionedSegmentsList
- getStoreSequenceId() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
Returns completed sequence id per store.
- getStoreSizeUncompressed() - Method in class org.apache.hadoop.hbase.regionserver.HStore
- getStoreSizeUncompressed() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Returns The size of the store files, in bytes, uncompressed.
- getStoresRequiringCompaction(MajorCompactionRequest) - Method in class org.apache.hadoop.hbase.util.compaction.MajorCompactor
- getStoresRequiringCompaction(MajorCompactionRequest) - Method in class org.apache.hadoop.hbase.util.compaction.MajorCompactorTTL
- getStream() - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogWriter
- getStream() - Method in class org.apache.hadoop.hbase.rest.client.Response
-
Gets the input stream instance.
- getStream(boolean) - Method in class org.apache.hadoop.hbase.io.FSDataInputStreamWrapper
-
Get the stream to use.
- getStreamScanner(boolean, boolean, boolean, long, long, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HStoreFile
-
Get a scanner which uses streaming read.
- getStreamSlowMonitor(String) - Method in class org.apache.hadoop.hbase.io.asyncfs.monitor.ExcludeDatanodeManager
- getStringCollection(String) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
- getStrings(String) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
- getStrings(String, String...) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
- getStripeBoundaries() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
- getStripeCompactMaxFiles() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreConfig
- getStripeCompactMinFiles() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreConfig
- getStripeCount() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
- getStripes() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
- getSubmittedCounter() - Method in class org.apache.hadoop.hbase.metrics.OperationMetrics
- getSuccessfulCoalescings() - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
- getSuccessfulCoalescings() - Method in interface org.apache.hadoop.hbase.thrift.IncrementCoalescerMBean
- getSuccessfulLogRolls() - Method in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
- getSuccessfulLogRolls() - Method in class org.apache.hadoop.hbase.regionserver.wal.MetricsWALSourceImpl
- getSuffix(byte[]) - Static method in class org.apache.hadoop.hbase.mapreduce.MultiTableHFileOutputFormat
- getSumHitCachingCountsPastNPeriods() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
- getSumHitCachingCountsPastNPeriods() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
- getSumHitCountsPastNPeriods() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
- getSumHitCountsPastNPeriods() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
- getSummary() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenModel
- getSumRequestCachingCountsPastNPeriods() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
- getSumRequestCachingCountsPastNPeriods() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
- getSumRequestCountsPastNPeriods() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
- getSumRequestCountsPastNPeriods() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
- getSuperGroups() - Static method in class org.apache.hadoop.hbase.security.Superusers
- getSuperUsers() - Static method in class org.apache.hadoop.hbase.security.Superusers
- getSupportedAlgorithms() - Static method in class org.apache.hadoop.hbase.io.compress.Compression
-
Get names of supported compression algorithms.
- getSupportedCiphers() - Method in interface org.apache.hadoop.hbase.io.crypto.CipherProvider
-
Return the set of Ciphers supported by this provider
- getSupportedCiphers() - Method in class org.apache.hadoop.hbase.io.crypto.CryptoCipherProvider
- getSupportedCiphers() - Method in class org.apache.hadoop.hbase.io.crypto.DefaultCipherProvider
- getSupportedCiphers() - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
-
Get names of supported encryption algorithms
- getSupportedCiphers(Configuration) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
-
Get names of supported encryption algorithms
- getSupportedCompressionAlgorithms() - Static method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Get supported compression algorithms.
- getSupportedCompressionAlgorithms() - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
-
Get names of supported compression algorithms.
- getSupportedFilters() - Method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Return a Set of filters supported by the Filter Language
- getSweepFuture() - Method in class org.apache.hadoop.hbase.util.LossyCounting
- getSyncedLength() - Method in interface org.apache.hadoop.hbase.io.asyncfs.AsyncFSOutput
-
Returns byteSize success synced to underlying filesystem.
- getSyncedLength() - Method in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutput
- getSyncedLength() - Method in class org.apache.hadoop.hbase.io.asyncfs.WrapperAsyncFSOutput
- getSyncedLength() - Method in class org.apache.hadoop.hbase.regionserver.wal.AsyncProtobufLogWriter
- getSyncedLength() - Method in class org.apache.hadoop.hbase.regionserver.wal.CombinedWriterBase
- getSyncedLength() - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogWriter
- getSyncedLength() - Method in interface org.apache.hadoop.hbase.wal.WALProvider.WriterBase
-
NOTE: We add this method for
WALFileLengthProvider
used for replication, considering the case if we useAsyncFSWAL
,we write to 3 DNs concurrently, according to the visibility guarantee of HDFS, the data will be available immediately when arriving at DN since all the DNs will be considered as the last one in pipeline. - getSyncedTxid(long, long) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
This method is to adapt
FSHLog
andAsyncFSWAL
. - getSyncFuture(long, boolean) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
- getSyncReplicationPeerIdFromWALName(String) - Static method in class org.apache.hadoop.hbase.wal.AbstractWALProvider
-
Returns the peer id if the wal file name is in the special group for a sync replication peer.
- getSyncReplicationPeerInfoProvider() - Method in interface org.apache.hadoop.hbase.regionserver.ReplicationSourceService
-
Returns an info provider for sync replication peer.
- getSyncReplicationPeerLock() - Method in class org.apache.hadoop.hbase.master.HMaster
- getSyncReplicationPeerLock() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Returns the SyncReplicationPeerLock.
- getSyncReplicationReplayWALManager() - Method in class org.apache.hadoop.hbase.master.HMaster
- getSyncReplicationReplayWALManager() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Returns the
SyncReplicationReplayWALManager
. - getSyncReplicationState() - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeer
-
Returns the sync replication state of the peer by reading local cache.
- getSyncReplicationState() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerDescription
- getSyncReplicationState() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerImpl
- getSyncReplicationStateAndNewState() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerImpl
- getSyncReplicationStateNode(String) - Method in class org.apache.hadoop.hbase.replication.ZKReplicationPeerStorage
- getSyncWaitTimeout() - Method in interface org.apache.hadoop.hbase.client.Admin
-
Return the blocking wait time for an asynchronous operation.
- getSystemLoadAverage() - Method in class org.apache.hadoop.hbase.util.JVM
-
Get the system load average
- getSystemUser() - Static method in class org.apache.hadoop.hbase.security.Superusers
- getTable() - Method in class org.apache.hadoop.hbase.backup.BackupTableInfo
- getTable() - Method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Returns current table name of the region
- getTable() - Method in class org.apache.hadoop.hbase.client.replication.TableCFs
- getTable() - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
-
Allows subclasses to get the
Table
. - getTable() - Method in class org.apache.hadoop.hbase.mapred.TableSplit
-
Returns table name
- getTable() - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
Allows subclasses to get the
Table
. - getTable() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
-
Returns the table name.
- getTable(byte[]) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Gets the table name from the specified region name.
- getTable(byte[]) - Method in class org.apache.hadoop.hbase.thrift.HBaseServiceHandler
-
Creates and returns a Table instance from a given table name.
- getTable(String) - Method in class org.apache.hadoop.hbase.util.ConnectionCache
-
Caller closes the table afterwards.
- getTable(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.HBaseServiceHandler
- getTable(TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncConnection
-
Retrieve an
AsyncTable
implementation for accessing a table. - getTable(TableName) - Method in interface org.apache.hadoop.hbase.client.Connection
-
Retrieve a Table implementation for accessing a table.
- getTable(TableName, ExecutorService) - Method in interface org.apache.hadoop.hbase.client.AsyncConnection
-
Retrieve an
AsyncTable
implementation for accessing a table. - getTable(TableName, ExecutorService) - Method in interface org.apache.hadoop.hbase.client.Connection
-
Retrieve a Table implementation for accessing a table.
- getTableAggregate() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceFactory
-
Get a MetricsTableAggregateSource
- getTableAggregate() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceFactoryImpl
- getTableArchivePath(Configuration, TableName) - Static method in class org.apache.hadoop.hbase.util.HFileArchiveUtil
-
Get the path to the table archive directory based on the configured archive directory.
- getTableArchivePath(Path, TableName) - Static method in class org.apache.hadoop.hbase.util.HFileArchiveUtil
-
Get the path to the table archive directory based on the configured archive directory.
- getTableBackupDir(String, String, TableName) - Static method in class org.apache.hadoop.hbase.backup.HBackupFileSystem
-
Given the backup root dir, backup id and the table name, return the backup image location.
- getTableBackupDir(TableName) - Method in class org.apache.hadoop.hbase.backup.BackupInfo
- getTableBackupPath(TableName, Path, String) - Static method in class org.apache.hadoop.hbase.backup.HBackupFileSystem
-
Given the backup root dir, backup id and the table name, return the backup image location, which is also where the backup manifest file is.
- getTableBuilder(TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncConnection
-
Returns an
AsyncTableBuilder
for creatingAsyncTable
. - getTableBuilder(TableName) - Method in class org.apache.hadoop.hbase.client.AsyncConnectionImpl
- getTableBuilder(TableName) - Method in class org.apache.hadoop.hbase.client.SharedAsyncConnection
- getTableBuilder(TableName, ExecutorService) - Method in interface org.apache.hadoop.hbase.client.AsyncConnection
-
Returns an
AsyncTableBuilder
for creatingAsyncTable
. - getTableBuilder(TableName, ExecutorService) - Method in class org.apache.hadoop.hbase.client.AsyncConnectionImpl
- getTableBuilder(TableName, ExecutorService) - Method in interface org.apache.hadoop.hbase.client.Connection
-
Returns an
TableBuilder
for creatingTable
. - getTableBuilder(TableName, ExecutorService) - Method in class org.apache.hadoop.hbase.client.SharedAsyncConnection
- getTableBuilder(TableName, ExecutorService) - Method in class org.apache.hadoop.hbase.client.SharedConnection
- getTableBySnapshot(String) - Method in class org.apache.hadoop.hbase.backup.BackupInfo
- getTableCF(ReplicationProtos.TableCF[], String) - Static method in class org.apache.hadoop.hbase.client.replication.ReplicationPeerConfigUtil
-
Get TableCF in TableCFs, if not exist, return null.
- getTableCFs() - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeer
-
Get replicable (table, cf-list) map of this peer
- getTableCFs() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerImpl
- getTableCFsMap() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
- getTableDescriptor() - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.InputSplit
- getTableDescriptor() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
- getTableDescriptor() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Returns table descriptor for this region
- getTableDescriptor() - Method in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper.RestoreMetaChanges
- getTableDescriptor() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotManifest
-
Get the table descriptor from the Snapshot
- getTableDescriptor(PerformanceEvaluation.TestOptions) - Static method in class org.apache.hadoop.hbase.PerformanceEvaluation
-
Create an HTableDescriptor from provided TestOptions.
- getTableDescriptorFromFs(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSTableDescriptors
-
Returns the latest table descriptor for the table located at the given directory directly from the file system if it exists.
- getTableDescriptorFromFs(FileSystem, Path, TableName) - Static method in class org.apache.hadoop.hbase.util.FSTableDescriptors
-
Returns the latest table descriptor for the given table directly from the file system if it exists, bypassing the local cache.
- getTableDescriptors() - Method in class org.apache.hadoop.hbase.HBaseServerBase
-
Returns Return table descriptors implementation.
- getTableDescriptors() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Returns Return table descriptors implementation.
- getTableDescriptors() - Method in class org.apache.hadoop.hbase.MockRegionServerServices
- getTableDescriptors() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
Returns Return table descriptors implementation.
- getTableDescriptors() - Method in class org.apache.hadoop.hbase.replication.ReplicationEndpoint.Context
- getTableDescriptors(RpcController, MasterProtos.GetTableDescriptorsRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
Get list of TableDescriptors for requested tables.
- getTableDir() - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
Returns
Path
to the region's root directory. - getTableDir(Path, TableName) - Static method in class org.apache.hadoop.hbase.util.CommonFSUtils
-
Returns the
Path
object representing the table directory under path rootdir - getTableDirs(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
- getTableEncodedRegionNameAndLastBarrier(Connection, TableName) - Static method in class org.apache.hadoop.hbase.replication.ReplicationBarrierFamilyFormat
- getTableEncodedRegionNamesForSerialReplication(Connection, TableName) - Static method in class org.apache.hadoop.hbase.replication.ReplicationBarrierFamilyFormat
- getTableFamilyDescForMeta(Configuration) - Static method in class org.apache.hadoop.hbase.util.FSTableDescriptors
- getTableFilter() - Method in class org.apache.hadoop.hbase.quotas.QuotaFilter
-
Returns the Table filter regex
- getTableFragmentation(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Runs through the HBase rootdir and checks how many stores for each table have more than one file in them.
- getTableFragmentation(HMaster) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Runs through the HBase rootdir and checks how many stores for each table have more than one file in them.
- getTableFromRowKey(byte[]) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
- getTableHRegionLocations(AsyncTable<AdvancedScanResultConsumer>, TableName) - Static method in class org.apache.hadoop.hbase.ClientMetaTableAccessor
-
Used to get all region locations for the specific table
- getTableInfo() - Method in interface org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandler
- getTableInfo() - Method in class org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandlerImpl
- getTableLimiter(TableName) - Method in class org.apache.hadoop.hbase.quotas.QuotaCache
-
Returns the limiter associated to the specified table.
- getTableLimiter(TableName) - Method in class org.apache.hadoop.hbase.quotas.UserQuotaState
-
Return the limiter for the specified table associated with this quota.
- getTableList() - Method in class org.apache.hadoop.hbase.backup.BackupRequest
- getTableListAsString() - Method in class org.apache.hadoop.hbase.backup.BackupInfo
- getTableName() - Method in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCaller
- getTableName() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
- getTableName() - Method in class org.apache.hadoop.hbase.client.LogQueryFilter
-
Deprecated.
- getTableName() - Method in class org.apache.hadoop.hbase.client.SnapshotDescription
- getTableName() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
Get the name of the table
- getTableName() - Method in class org.apache.hadoop.hbase.client.TableState
-
Table name for state
- getTableName() - Method in class org.apache.hadoop.hbase.HbckRegionDetails
- getTableName() - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
- getTableName() - Method in class org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
- getTableName() - Method in interface org.apache.hadoop.hbase.ipc.HBaseRpcController
-
Returns Region's table name or null if not available or pertinent.
- getTableName() - Method in class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
- getTableName() - Method in class org.apache.hadoop.hbase.mapred.TableSplit
-
Returns table name
- getTableName() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
-
Returns the table name converted to a byte array.
- getTableName() - Method in class org.apache.hadoop.hbase.quotas.policies.AbstractViolationPolicyEnforcement
- getTableName() - Method in class org.apache.hadoop.hbase.quotas.QuotaSettings
- getTableName() - Method in class org.apache.hadoop.hbase.regionserver.HStore
- getTableName() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
-
Get the name of the table the region belongs to.
- getTableName() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
- getTableName() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableSource
- getTableName() - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableSourceImpl
- getTableName() - Method in interface org.apache.hadoop.hbase.regionserver.Store
- getTableName() - Method in class org.apache.hadoop.hbase.regionserver.StoreContext
- getTableName() - Method in class org.apache.hadoop.hbase.regionserver.storefiletracker.ModifyStoreFileTrackerProcedure
- getTableName() - Method in class org.apache.hadoop.hbase.util.HbckRegionInfo
- getTableName() - Method in interface org.apache.hadoop.hbase.wal.WALKey
-
Returns table name
- getTableName() - Method in class org.apache.hadoop.hbase.wal.WALKeyImpl
-
Returns table name
- getTableName(byte[]) - Static method in class org.apache.hadoop.hbase.mapreduce.MultiTableHFileOutputFormat
- getTableName(Path) - Static method in class org.apache.hadoop.hbase.util.CommonFSUtils
-
Returns the
TableName
object representing the table directory under path rootdir - getTableName(Path) - Static method in class org.apache.hadoop.hbase.util.HFileArchiveUtil
- getTableName(ExtendedCell) - Static method in class org.apache.hadoop.hbase.mob.MobUtils
-
Get the table name from when this cell was written into a mob hfile as a TableName.
- getTableNameArray(List<HBaseProtos.TableName>) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
- getTableNameAsString() - Method in class org.apache.hadoop.hbase.client.SnapshotDescription
- getTableNamePrefix() - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableSourceImpl
- getTableNames() - Method in class org.apache.hadoop.hbase.backup.BackupInfo
- getTableNames() - Method in class org.apache.hadoop.hbase.client.NormalizeTableFilterParams
- getTableNames() - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
- getTableNames(RpcController, MasterProtos.GetTableNamesRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
Get list of userspace table names
- getTableNamespaceManager() - Method in interface org.apache.hadoop.hbase.master.ClusterSchema
-
For internals use only.
- getTableNameString(ExtendedCell) - Static method in class org.apache.hadoop.hbase.mob.MobUtils
-
Gets the table name from when this cell was written into a mob hfile as a string.
- getTableNameSuffixedWithFamily(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
- getTableNamesWithIsTableEnabled() - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
- getTableOperationType() - Method in class org.apache.hadoop.hbase.regionserver.storefiletracker.ModifyStoreFileTrackerProcedure
- getTableQuota(Connection, TableName) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
- getTableQuotaSnapshots() - Method in class org.apache.hadoop.hbase.quotas.QuotaObserverChore
-
Returns an unmodifiable view over the current
SpaceQuotaSnapshot
objects for each HBase table with a quota defined. - getTableRegions(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
-
Returns the list of regions in the given table, or an empty list if the table does not exist
- getTableRegions(Connection, TableName) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Gets all of the regions of the specified table.
- getTableRegions(Connection, TableName, boolean) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Gets all of the regions of the specified table.
- getTableRegionsAndLocations(Connection, TableName) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Do not use this method to get meta table regions, use methods in MetaTableLocator instead.
- getTableRegionsAndLocations(Connection, TableName, boolean) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Do not use this method to get meta table regions, use methods in MetaTableLocator instead.
- getTableRegionStatesCount() - Method in interface org.apache.hadoop.hbase.ClusterMetrics
-
Provide region states count for given table.
- getTableResource(String) - Method in class org.apache.hadoop.hbase.rest.RootResource
- getTableRowKey(TableName) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
- getTableRowKeyRegex(String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
- getTables() - Method in class org.apache.hadoop.hbase.backup.BackupInfo
- getTables() - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
-
Deprecated.Since 3.0.0, will be removed in 4.0.0. The rsgroup information will be stored in the configuration of a table so this will be removed.
- getTableSet() - Method in class org.apache.hadoop.hbase.master.SnapshotOfRegionAssignmentFromMeta
-
Get the table set
- getTableSetTimestampMap() - Method in class org.apache.hadoop.hbase.backup.BackupInfo
- getTableSize(String) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregate
-
Get the table region size against this table
- getTableSize(String) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImpl
- getTableSnapshots(Connection) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
Returns a multimap for all existing table snapshot entries.
- getTableSourceAgg() - Method in class org.apache.hadoop.hbase.regionserver.MetricsTable
- getTableSpaceUtilization() - Method in interface org.apache.hadoop.hbase.master.MetricsMasterWrapper
-
Gets the space usage and limit for each table.
- getTableSpaceUtilization() - Method in class org.apache.hadoop.hbase.master.MetricsMasterWrapperImpl
- getTableStartRowForMeta(TableName, ClientMetaTableAccessor.QueryType) - Static method in class org.apache.hadoop.hbase.ClientMetaTableAccessor
-
Returns start row for scanning META according to query type
- getTableState(AsyncTable<?>, TableName) - Static method in class org.apache.hadoop.hbase.ClientMetaTableAccessor
- getTableState(Connection, TableName) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Fetch table state for given table from META table
- getTableState(Result) - Static method in class org.apache.hadoop.hbase.CatalogFamilyFormat
-
Decode table state from META Result.
- getTableState(TableName) - Method in class org.apache.hadoop.hbase.master.TableStateManager
- getTableState(RpcController, MasterProtos.GetTableStateRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- getTableStateManager() - Method in class org.apache.hadoop.hbase.master.HMaster
- getTableStateManager() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Returns Master's instance of
TableStateManager
- getTableStates(Connection) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Fetch table states from META table
- getTableStopRowForMeta(TableName, ClientMetaTableAccessor.QueryType) - Static method in class org.apache.hadoop.hbase.ClientMetaTableAccessor
-
Returns stop row for scanning META according to query type
- getTableStoreFilePathMap(Map<String, Path>, FileSystem, Path, TableName) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Runs through the HBase rootdir/tablename and creates a reverse lookup map for table StoreFile names to the full Path.
- getTableStoreFilePathMap(Map<String, Path>, FileSystem, Path, TableName, PathFilter, ExecutorService, FSUtils.ProgressReporter) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Runs through the HBase rootdir/tablename and creates a reverse lookup map for table StoreFile names to the full Path.
- getTableStoreFilePathMap(Map<String, Path>, FileSystem, Path, TableName, PathFilter, ExecutorService, HbckErrorReporter) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Deprecated.Since 2.3.0. For removal in hbase4. Use ProgressReporter override instead.
- getTableStoreFilePathMap(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Runs through the HBase rootdir and creates a reverse lookup map for table StoreFile names to the full Path.
- getTableStoreFilePathMap(FileSystem, Path, PathFilter, ExecutorService, FSUtils.ProgressReporter) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Runs through the HBase rootdir and creates a reverse lookup map for table StoreFile names to the full Path.
- getTableStoreFilePathMap(FileSystem, Path, PathFilter, ExecutorService, HbckErrorReporter) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Deprecated.Since 2.3.0. Will be removed in hbase4. Used
FSUtils.getTableStoreFilePathMap(FileSystem, Path, PathFilter, ExecutorService, ProgressReporter)
- getTableToRegionMap() - Method in class org.apache.hadoop.hbase.master.SnapshotOfRegionAssignmentFromMeta
-
Get regions for tables
- getTableWrapper() - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableSourceImpl
- getTableWrapperAgg() - Method in class org.apache.hadoop.hbase.regionserver.MetricsTable
- getTag(byte) - Method in class org.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValue
- getTag(byte) - Method in interface org.apache.hadoop.hbase.RawCell
-
Returns the specific tag of the given type
- getTag(ExtendedCell, byte) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
Retrieve Cell's first tag, matching the passed in type
- getTagCompressionContext() - Method in class org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultDecodingContext
- getTagCompressionContext() - Method in class org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultEncodingContext
- getTags() - Method in class org.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValue
- getTags() - Method in interface org.apache.hadoop.hbase.RawCell
-
Creates a list of tags in the current cell
- getTags(ExtendedCell) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
Return tags in the given Cell as a List
- getTagsArray() - Method in class org.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValue
- getTagsArray() - Method in class org.apache.hadoop.hbase.ByteBufferKeyValue
- getTagsArray() - Method in class org.apache.hadoop.hbase.IndividualBytesFieldCell
- getTagsArray() - Method in class org.apache.hadoop.hbase.KeyValue
-
Returns the backing array of the entire KeyValue (all KeyValue fields are in a single array)
- getTagsArray() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
- getTagsArray() - Method in class org.apache.hadoop.hbase.NoTagsByteBufferKeyValue
- getTagsArray() - Method in interface org.apache.hadoop.hbase.RawCell
-
Contiguous raw bytes representing tags that may start at any index in the containing array.
- getTagsArray() - Method in class org.apache.hadoop.hbase.util.MapReduceExtendedCell
- getTagsByteBuffer() - Method in class org.apache.hadoop.hbase.ByteBufferExtendedCell
-
Returns The
ByteBuffer
containing the tag bytes. - getTagsByteBuffer() - Method in class org.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValue
- getTagsByteBuffer() - Method in class org.apache.hadoop.hbase.ByteBufferKeyValue
- getTagsByteBuffer() - Method in class org.apache.hadoop.hbase.util.MapReduceExtendedCell
- getTagsLength() - Method in class org.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValue
- getTagsLength() - Method in class org.apache.hadoop.hbase.ByteBufferKeyValue
- getTagsLength() - Method in class org.apache.hadoop.hbase.IndividualBytesFieldCell
- getTagsLength() - Method in class org.apache.hadoop.hbase.KeyValue
-
Return the total length of the tag bytes
- getTagsLength() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
- getTagsLength() - Method in class org.apache.hadoop.hbase.NoTagsByteBufferKeyValue
- getTagsLength() - Method in class org.apache.hadoop.hbase.NoTagsKeyValue
- getTagsLength() - Method in interface org.apache.hadoop.hbase.RawCell
-
HBase internally uses 2 bytes to store tags length in Cell.
- getTagsLength() - Method in class org.apache.hadoop.hbase.SizeCachedNoTagsKeyValue
- getTagsLength() - Method in class org.apache.hadoop.hbase.util.MapReduceExtendedCell
- getTagsOffset() - Method in class org.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValue
- getTagsOffset() - Method in class org.apache.hadoop.hbase.ByteBufferKeyValue
- getTagsOffset() - Method in class org.apache.hadoop.hbase.IndividualBytesFieldCell
- getTagsOffset() - Method in class org.apache.hadoop.hbase.KeyValue
-
Return the offset where the tag data starts.
- getTagsOffset() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
- getTagsOffset() - Method in interface org.apache.hadoop.hbase.RawCell
-
Return the first offset where the tags start in the Cell
- getTagsOffset() - Method in class org.apache.hadoop.hbase.util.MapReduceExtendedCell
- getTagsPosition() - Method in class org.apache.hadoop.hbase.ByteBufferExtendedCell
-
Returns Position in the
ByteBuffer
where tag bytes start - getTagsPosition() - Method in class org.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValue
- getTagsPosition() - Method in class org.apache.hadoop.hbase.ByteBufferKeyValue
- getTagsPosition() - Method in class org.apache.hadoop.hbase.util.MapReduceExtendedCell
- getTail() - Method in class org.apache.hadoop.hbase.regionserver.CompactionPipeline
- getTailSize() - Method in class org.apache.hadoop.hbase.regionserver.CompactionPipeline
- getTargetRootDir() - Method in class org.apache.hadoop.hbase.backup.BackupRequest
- getTargetServerName(Result, int) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Returns the
ServerName
from catalog tableResult
where the region is transitioning on. - getTargetState(String, QuotaProtos.SpaceQuota) - Method in class org.apache.hadoop.hbase.quotas.NamespaceQuotaSnapshotStore
- getTargetState(TableName, QuotaProtos.SpaceQuota) - Method in class org.apache.hadoop.hbase.quotas.TableQuotaSnapshotStore
- getTargetState(T, QuotaProtos.SpaceQuota) - Method in interface org.apache.hadoop.hbase.quotas.QuotaSnapshotStore
-
Computes the target
SpaceQuotaSnapshot
for the givensubject
andspaceQuota
. - getTaskNode() - Method in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination.ZkSplitTaskDetails
- getTaskReadySeq() - Method in interface org.apache.hadoop.hbase.coordination.SplitLogWorkerCoordination
-
Deprecated.Used by unit tests to check how many tasks were processed
- getTaskReadySeq() - Method in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination
- getTaskReadySeq() - Method in class org.apache.hadoop.hbase.regionserver.SplitLogWorker
-
Deprecated.Returns the number of tasks processed by coordination.
- getTasks() - Method in class org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination.SplitLogManagerDetails
-
Deprecated.Returns map of tasks
- getTasks() - Method in interface org.apache.hadoop.hbase.ServerMetrics
-
Called directly from clients such as the hbase shell
- getTempDir() - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
-
Returns HBase temp dir.
- getTempDir() - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
Returns
Path
to the region's temp directory, used for file creations - getTerminal() - Method in class org.apache.hadoop.hbase.hbtop.screen.AbstractScreenView
- getTerminalPrinter(int) - Method in class org.apache.hadoop.hbase.hbtop.screen.AbstractScreenView
- getTerminalPrinter(int) - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.batch.BatchTerminal
- getTerminalPrinter(int) - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.TerminalImpl
- getTerminalPrinter(int) - Method in interface org.apache.hadoop.hbase.hbtop.terminal.Terminal
- getTerminalSize() - Method in class org.apache.hadoop.hbase.hbtop.screen.AbstractScreenView
- getTerminalSize() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenView
- getTertiaryToRegionInfoMap() - Method in class org.apache.hadoop.hbase.master.SnapshotOfRegionAssignmentFromMeta
- getTestFileSystem() - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- getThird() - Method in class org.apache.hadoop.hbase.util.Triple
- getThriftServerType() - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
- getThriftServerType() - Method in class org.apache.hadoop.hbase.thrift.ThriftMetrics
- getThrottleProto() - Method in class org.apache.hadoop.hbase.quotas.GlobalQuotaSettingsImpl
- getThrottleType() - Method in class org.apache.hadoop.hbase.quotas.ThrottleSettings
- getThroughputControllerClass(Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.throttle.CompactionThroughputControllerFactory
- getThroughputControllerClass(Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.throttle.FlushThroughputControllerFactory
- getThrowable() - Method in class org.apache.hadoop.hbase.tool.coprocessor.CoprocessorViolation
- getTHsHaServer(TNonblockingServerTransport, TProtocolFactory, TProcessor, TTransportFactory, InetSocketAddress) - Method in class org.apache.hadoop.hbase.thrift.ThriftServer
- getTimeDuration(String, long, TimeUnit) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
- getTimeHisto() - Method in class org.apache.hadoop.hbase.metrics.OperationMetrics
- getTimeOfDeath(ServerName) - Method in class org.apache.hadoop.hbase.master.DeadServer
-
Get the time when a server died
- getTimeout() - Method in interface org.apache.hadoop.hbase.ipc.RpcCall
-
Returns The timeout of this call.
- getTimeout() - Method in class org.apache.hadoop.hbase.ipc.ServerCall
- getTimeout() - Method in class org.apache.hadoop.hbase.replication.ReplicationEndpoint.ReplicateContext
- getTimeRange() - Method in class org.apache.hadoop.hbase.client.Append
-
Gets the TimeRange used for this append.
- getTimeRange() - Method in class org.apache.hadoop.hbase.client.CheckAndMutate
-
Returns the time range to check
- getTimeRange() - Method in class org.apache.hadoop.hbase.client.Get
-
Method for retrieving the get's TimeRange
- getTimeRange() - Method in class org.apache.hadoop.hbase.client.ImmutableScan
- getTimeRange() - Method in class org.apache.hadoop.hbase.client.Increment
-
Gets the TimeRange used for this increment.
- getTimeRange() - Method in class org.apache.hadoop.hbase.client.Scan
-
Returns TimeRange
- getTimeRangeTracker() - Method in class org.apache.hadoop.hbase.regionserver.CompositeImmutableSegment
- getTimeRangeTracker() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreSnapshot
-
Returns
TimeRangeTracker
for all the Cells in the snapshot. - getTimeRangeTracker() - Method in class org.apache.hadoop.hbase.regionserver.Segment
- getTimestamp() - Method in class org.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValue
- getTimestamp() - Method in class org.apache.hadoop.hbase.ByteBufferKeyValue
- getTimestamp() - Method in interface org.apache.hadoop.hbase.Cell
-
Return a long value representing time at which this cell was "Put" into the row.
- getTimestamp() - Method in class org.apache.hadoop.hbase.client.Mutation
-
Method for retrieving the timestamp.
- getTimestamp() - Method in class org.apache.hadoop.hbase.IndividualBytesFieldCell
- getTimestamp() - Method in class org.apache.hadoop.hbase.KeyValue
-
Return the timestamp.
- getTimestamp() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
- getTimestamp() - Method in class org.apache.hadoop.hbase.rest.RowSpec
- getTimestamp() - Method in class org.apache.hadoop.hbase.util.MapReduceExtendedCell
- getTimestamp(String) - Static method in class org.apache.hadoop.hbase.wal.AbstractFSWALProvider
-
Split a WAL filename to get a start time.
- getTimeStamp() - Method in class org.apache.hadoop.hbase.namequeues.WALEventTrackerPayload
- getTimestampKeyColumnIndex() - Method in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
- getTimestampOffset() - Method in class org.apache.hadoop.hbase.KeyValue
-
Returns Timestamp offset
- getTimestampOffset() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
- getTimestampOfLastShippedOp() - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSource
- getTimeStampOfNextToReplicate() - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSource
- getTimestamps() - Method in class org.apache.hadoop.hbase.filter.TimestampsFilter
-
Returns the list of timestamps
- getTimestampsOfLastAppliedOp() - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSink
- getTimestampStarted() - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSink
- getTimestampString(KeyValue) - Static method in class org.apache.hadoop.hbase.KeyValueTestUtil
- getTimeToLive() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Returns Time-to-live of cell contents, in seconds.
- getTimeToPurgeDeletes() - Method in class org.apache.hadoop.hbase.regionserver.CustomizedScanInfoBuilder
- getTimeToPurgeDeletes() - Method in class org.apache.hadoop.hbase.regionserver.ScanInfo
- getTimeToPurgeDeletes() - Method in interface org.apache.hadoop.hbase.regionserver.ScanOptions
- getTimeUnit() - Method in class org.apache.hadoop.hbase.quotas.ThrottleSettings
- getTimeUnit() - Method in class org.apache.hadoop.hbase.ScheduledChore
- getTimeUnit() - Method in class org.apache.hadoop.hbase.util.RetryCounter.RetryConfig
- getTimeUnitInMillis() - Method in class org.apache.hadoop.hbase.quotas.RateLimiter
- getTmpDir(Configuration) - Static method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.Returns Return the tmp dir this tool writes too.
- getTNonBlockingServer(TNonblockingServerTransport, TProtocolFactory, TProcessor, TTransportFactory, InetSocketAddress) - Method in class org.apache.hadoop.hbase.thrift.ThriftServer
- getToken(String, String) - Method in class org.apache.hadoop.hbase.security.User
-
Returns the Token of the specified kind associated with this user, or null if the Token is not present.
- getTokenKind() - Method in class org.apache.hadoop.hbase.security.SecurityInfo
- getTokens() - Method in class org.apache.hadoop.hbase.security.User
-
Returns all the tokens stored in the user's credentials.
- getTopHosts() - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution
-
Return the sorted list of hosts in terms of their weights
- getTopHostsWithWeights() - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution
-
Return the sorted list of hosts in terms of their weights
- getToTables() - Method in class org.apache.hadoop.hbase.backup.RestoreRequest
- getTotalAndMaxNettyOutboundBytes() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapper
-
These two metrics are calculated together, so we want to return them in one call
- getTotalAndMaxNettyOutboundBytes() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapperImpl
- getTotalAndMaxNettyOutboundBytes() - Method in class org.apache.hadoop.hbase.ipc.NettyRpcServer
- getTotalBloomSize() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileReader
- getTotalBufferCount() - Method in class org.apache.hadoop.hbase.io.ByteBuffAllocator
- getTotalBytesCopied() - Method in class org.apache.hadoop.hbase.backup.BackupInfo
- getTotalBytesRead() - Static method in class org.apache.hadoop.hbase.io.FSDataInputStreamWrapper
- getTotalBytesRead() - Method in class org.apache.hadoop.hbase.io.hadoopbackport.ThrottledInputStream
-
Getter for the number of bytes read from this stream, since creation.
- getTotalBytesRead() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Returns Number of total bytes read from HDFS.
- getTotalIncrements() - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
- getTotalIncrements() - Method in interface org.apache.hadoop.hbase.thrift.IncrementCoalescerMBean
- getTotalOpsProcessed() - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSink
- getTotalPendingOutboundBytes(Channel) - Static method in class org.apache.hadoop.hbase.util.NettyUnsafeUtils
-
Get total bytes pending write to socket
- getTotalQueueSize() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapper
- getTotalQueueSize() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapperImpl
- getTotalRegions() - Method in class org.apache.hadoop.hbase.client.RegionStatesCount
- getTotalRequestCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the total number of requests per second.
- getTotalRequestCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
- getTotalRequestCount() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
- getTotalRequestsCount(String) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregate
-
Get the total number of requests that have been issued for this table
- getTotalRequestsCount(String) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImpl
- getTotalRequestsCount(ClusterStatusProtos.RegionLoad) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
- getTotalRowActionRequestCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
- getTotalSizeOfCells(Result) - Static method in class org.apache.hadoop.hbase.client.Result
-
Get total size of raw cells
- getTotalSleepTime() - Method in class org.apache.hadoop.hbase.io.hadoopbackport.ThrottledInputStream
-
Getter the total time spent in sleep.
- getTotalStaticBloomSize() - Method in class org.apache.hadoop.hbase.regionserver.HStore
- getTotalStaticBloomSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the size (in bytes) of the static bloom filters.
- getTotalStaticBloomSize() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Returns the total byte size of all Bloom filter bit arrays.
- getTotalStaticIndexSize() - Method in class org.apache.hadoop.hbase.regionserver.HStore
- getTotalStaticIndexSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the size (in bytes) of of the static indexes including the roots.
- getTotalStaticIndexSize() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Returns the total size of all index blocks in the data block indexes, including the root level, intermediate levels, and the leaf level for multi-level indexes, or just the root level for single-level indexes.
- getTotalTableFragmentation(HMaster) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Returns the total overall fragmentation percentage.
- getTotalTasks() - Method in class org.apache.hadoop.hbase.backup.BackupRequest
- getTotalUncompressedBytes() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
- getTotalUncompressedBytes() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileReader
- getTotalUncompressedBytes(List<HStoreFile>) - Static method in class org.apache.hadoop.hbase.regionserver.StoreUtils
- getTotalUncompressedSize() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexWriter
-
The total uncompressed size of the root index block, intermediate-level index blocks, and leaf-level index blocks.
- getTrackerClass(String) - Static method in class org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileTrackerFactory
- getTrackerClass(Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileTrackerFactory
- getTrackers(RegionCoprocessorHost, NavigableSet<byte[]>, ScanInfo, long, Scan) - Static method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher
- getTrailer() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
- getTrailer() - Method in class org.apache.hadoop.hbase.io.hfile.HFileInfo
- getTrailer() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
- getTrailerHitCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
- getTrailerHitCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
- getTrailerHitCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
- getTrailerMissCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
- getTrailerMissCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
- getTrailerMissCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
- getTrailerSize() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
- getTrimmed(String) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
- getTrimmed(String, String) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
- getTrimmedStringCollection(String) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
- getTrimmedStrings(String) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
- getTrimmedStrings(String, String...) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
- getTs() - Method in class org.apache.hadoop.hbase.mapreduce.TextSortReducer
- getTs() - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
- getTS(Path) - Static method in class org.apache.hadoop.hbase.wal.AbstractFSWALProvider.WALStartTimeComparator
-
Split a path to get the start time For example: 10.20.20.171%3A60020.1277499063250 Could also be a meta WAL which adds a '.meta' suffix or a synchronous replication WAL which adds a '.syncrep' suffix.
- getTserver() - Method in class org.apache.hadoop.hbase.thrift.ThriftServer
-
the thrift server, not null means the server is started, for test only
- getTThreadedSelectorServer(TNonblockingServerTransport, TProtocolFactory, TProcessor, TTransportFactory, InetSocketAddress) - Method in class org.apache.hadoop.hbase.thrift.ThriftServer
- getTThreadPoolServer(TProtocolFactory, TProcessor, TTransportFactory, InetSocketAddress) - Method in class org.apache.hadoop.hbase.thrift.ThriftServer
- getTtl() - Method in class org.apache.hadoop.hbase.client.SnapshotDescription
- getTtl() - Method in class org.apache.hadoop.hbase.regionserver.ScanInfo
- getTTL() - Method in class org.apache.hadoop.hbase.client.Mutation
-
Return the TTL requested for the result of the mutation, in milliseconds.
- getTTL() - Method in class org.apache.hadoop.hbase.regionserver.CustomizedScanInfoBuilder
- getTTL() - Method in interface org.apache.hadoop.hbase.regionserver.ScanOptions
- getType() - Method in class org.apache.hadoop.hbase.ArrayBackedTag
-
Returns the tag type
- getType() - Method in class org.apache.hadoop.hbase.backup.BackupInfo
- getType() - Method in class org.apache.hadoop.hbase.ByteBufferTag
- getType() - Method in interface org.apache.hadoop.hbase.Cell
-
Returns the type of cell in a human readable format using
Cell.Type
. - getType() - Method in class org.apache.hadoop.hbase.client.LogQueryFilter
-
Deprecated.
- getType() - Method in class org.apache.hadoop.hbase.client.SnapshotDescription
- getType() - Method in interface org.apache.hadoop.hbase.ExtendedCell
-
Typically, at server side, you'd better always use the
ExtendedCell.getTypeByte()
as this method does not expose theMaximum
andMinimum
because they will not be returned to client, but at server side, we do have cells with these types so if you use this method it will cause exceptions. - getType() - Method in class org.apache.hadoop.hbase.hbtop.terminal.KeyPress
- getType() - Method in exception org.apache.hadoop.hbase.quotas.RpcThrottlingException
- getType() - Method in interface org.apache.hadoop.hbase.Tag
-
Returns the tag type
- getType() - Method in class org.apache.hadoop.hbase.wal.WALSplitUtil.MutationReplay
- getTypeByte() - Method in class org.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValue
- getTypeByte() - Method in class org.apache.hadoop.hbase.ByteBufferKeyValue
- getTypeByte() - Method in interface org.apache.hadoop.hbase.ExtendedCell
-
Returns The byte representation of the KeyValue.TYPE of this cell: one of Put, Delete, etc
- getTypeByte() - Method in class org.apache.hadoop.hbase.IndividualBytesFieldCell
- getTypeByte() - Method in class org.apache.hadoop.hbase.KeyValue
-
Returns KeyValue.TYPE byte representation
- getTypeByte() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
- getTypeByte() - Method in class org.apache.hadoop.hbase.util.MapReduceExtendedCell
- getTypeByte(Cell) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
- getTypeFilters() - Method in class org.apache.hadoop.hbase.quotas.QuotaFilter
-
Returns the QuotaType types that we want to filter one
- getTypeString(KeyValue) - Static method in class org.apache.hadoop.hbase.KeyValueTestUtil
- getUGI() - Method in class org.apache.hadoop.hbase.security.User
- getUnassignMetrics() - Method in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
-
Returns
OperationMetrics
containing common metrics for unassign region operation - getUnassignMetrics() - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManagerSourceImpl
- getUnassignProcMetrics() - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManager
-
Returns Set of common metrics for unassign procedure
- getUnblockedFlushCount() - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerContext
- getUncachedBlockReader() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
- getUncachedBlockReader() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
-
For testing
- getUncompressedDataIndexSize() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
- getUncompressedSizeWithoutHeader() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
Returns the uncompressed size of data part (header and checksum excluded).
- getUncompressedStoreFileSize() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
Returns the uncompressed size of the storefiles
- getUnderlyingFileLinkInputStream(FSDataInputStream) - Static method in class org.apache.hadoop.hbase.io.FileLink
-
If the passed FSDataInputStream is backed by a FileLink, returns the underlying InputStream for the resolved link target.
- getUnencodedDataSizeWritten() - Method in class org.apache.hadoop.hbase.io.encoding.EncodingState
- getUniqueBlocksTotalWeight() - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution
-
Returns the sum of all unique blocks' weight
- getUniqueFile(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFileWriter
- getUnit() - Method in class org.apache.hadoop.hbase.Size
-
Returns size unit
- getUnit(String) - Static method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
- getUnit(String) - Static method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
- getUnknownServerNames() - Method in interface org.apache.hadoop.hbase.ClusterMetrics
-
Returns the names of region servers on the unknown list
- getUnneededFiles(long, List<HStoreFile>) - Method in interface org.apache.hadoop.hbase.regionserver.StoreFileManager
- getUnneededFiles(long, List<HStoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
- getUpdatesBlockedMsHighWater() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreFlusher
- getUpdatesBlockedTime() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the amount of time that updates were blocked.
- getUrl() - Static method in class org.apache.hadoop.hbase.util.VersionInfo
-
Get the subversion URL for the root hbase directory.
- getUsage() - Method in class org.apache.hadoop.hbase.master.HMasterCommandLine
- getUsage() - Method in class org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot
-
Returns the current usage, in bytes, of the target (e.g.
- getUsage() - Method in interface org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshotView
-
Returns the current usage, in bytes, of the target (e.g.
- getUsage() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServerCommandLine
- getUsage() - Method in class org.apache.hadoop.hbase.util.ServerCommandLine
-
Implementing subclasses should return a usage string to print out.
- getUsedBufferCount() - Method in class org.apache.hadoop.hbase.io.ByteBuffAllocator
- getUsedHeapSize() - Method in interface org.apache.hadoop.hbase.ServerMetrics
-
Returns the amount of used heap
- getUser() - Method in class org.apache.hadoop.hbase.client.AsyncConnectionImpl
- getUser() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsUserSource
- getUser() - Method in class org.apache.hadoop.hbase.regionserver.MetricsUserSourceImpl
- getUser() - Static method in class org.apache.hadoop.hbase.util.VersionInfo
-
The user that compiled hbase.
- getUserAggregate() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceFactory
-
Return the singleton instance for MetricsUserAggregateSource
- getUserAggregate() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceFactoryImpl
- getUserFilter() - Method in class org.apache.hadoop.hbase.quotas.QuotaFilter
-
Returns the User filter regex
- getUserFromPrincipal(String) - Static method in class org.apache.hadoop.hbase.security.SecurityUtil
-
Get the user name from a principal
- getUserFromRowKey(byte[]) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
- getUserLimiter(UserGroupInformation, TableName) - Method in class org.apache.hadoop.hbase.quotas.QuotaCache
-
Returns the limiter associated to the specified user/table.
- getUserMetrics() - Method in interface org.apache.hadoop.hbase.ServerMetrics
-
Returns metrics per user
- getUserName() - Method in class org.apache.hadoop.hbase.client.LogQueryFilter
-
Deprecated.
- getUserName() - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord
- getUserName() - Method in class org.apache.hadoop.hbase.quotas.QuotaSettings
- getUserName() - Method in interface org.apache.hadoop.hbase.UserMetrics
-
Returns the user name
- getUserPermissions(GetUserPermissionsRequest) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get the global/namespace/table permissions for user
- getUserPermissions(GetUserPermissionsRequest) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Get the global/namespace/table permissions for user
- getUserPermissions(RpcController, AccessControlProtos.GetUserPermissionsRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- getUserQuota(Connection, String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
- getUserQuota(Connection, String, String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
- getUserQuota(Connection, String, TableName) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
- getUserQuotaState(UserGroupInformation) - Method in class org.apache.hadoop.hbase.quotas.QuotaCache
-
Returns the QuotaState associated to the specified user.
- getUserRowKey(String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
- getUserRowKeyRegex(String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
- getUserSources() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsUserAggregateSource
- getUserSources() - Method in class org.apache.hadoop.hbase.regionserver.MetricsUserAggregateSourceImpl
- getUseThisHostnameInstead(Configuration) - Method in class org.apache.hadoop.hbase.HBaseServerBase
- getUseThisHostnameInstead(Configuration) - Method in class org.apache.hadoop.hbase.master.HMaster
- getUseThisHostnameInstead(Configuration) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
- getUtf8ByteArrays(List<String>) - Static method in class org.apache.hadoop.hbase.util.Bytes
- getUUIDForCluster(ZKWatcher) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKClusterId
-
Get the UUID for the provided ZK watcher.
- getValByRegex(String) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
- getValue() - Method in class org.apache.hadoop.hbase.client.CheckAndMutate
-
Returns the expected value
- getValue() - Method in enum class org.apache.hadoop.hbase.client.security.SecurityCapability
- getValue() - Method in class org.apache.hadoop.hbase.filter.ByteArrayComparable
- getValue() - Method in class org.apache.hadoop.hbase.filter.SubstringComparator
- getValue() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.EncodedScanner
- getValue() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
- getValue() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
-
Gets a buffer view to the current value.
- getValue() - Method in interface org.apache.hadoop.hbase.metrics.Gauge
- getValue() - Method in enum class org.apache.hadoop.hbase.namequeues.NamedQueuePayload.NamedQueueEvent
- getValue(byte[]) - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Get a configuration value.
- getValue(byte[]) - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
Getter for accessing the metadata associated with the key.
- getValue(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Result
-
Get the latest version of the specified column.
- getValue(byte[], byte[], Cell) - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
-
Returns value of type T
- getValue(String) - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Get a configuration value.
- getValue(String) - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
Getter for accessing the metadata associated with the key.
- getValue(String) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
- getValue(String) - Static method in enum class org.apache.hadoop.hbase.KeepDeletedCells
- getValue(Bytes) - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Get a configuration value.
- getValue(Bytes) - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
Getter for accessing the metadata associated with the key.
- getValueArray() - Method in class org.apache.hadoop.hbase.ArrayBackedTag
-
Returns The byte array backing this Tag.
- getValueArray() - Method in class org.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValue
- getValueArray() - Method in class org.apache.hadoop.hbase.ByteBufferKeyValue
- getValueArray() - Method in class org.apache.hadoop.hbase.ByteBufferTag
- getValueArray() - Method in interface org.apache.hadoop.hbase.Cell
-
Contiguous raw bytes that may start at any index in the containing array.
- getValueArray() - Method in class org.apache.hadoop.hbase.IndividualBytesFieldCell
- getValueArray() - Method in class org.apache.hadoop.hbase.KeyValue
-
Returns the backing array of the entire KeyValue (all KeyValue fields are in a single array)
- getValueArray() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
- getValueArray() - Method in interface org.apache.hadoop.hbase.Tag
-
Return an array containing the value bytes if
Tag.hasArray()
returns true. - getValueArray() - Method in class org.apache.hadoop.hbase.util.MapReduceExtendedCell
- getValueAsBigDecimal(Cell) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
Converts the value bytes of the given cell into a BigDecimal
- getValueAsByte(Tag) - Static method in interface org.apache.hadoop.hbase.Tag
-
Converts the value bytes of the given tag into a byte value
- getValueAsByteBuffer(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Result
-
Returns the value wrapped in a new
ByteBuffer
. - getValueAsByteBuffer(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.client.Result
-
Returns the value wrapped in a new
ByteBuffer
. - getValueAsDouble(Cell) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
Converts the value bytes of the given cell into a double value
- getValueAsInt(Cell) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
Converts the value bytes of the given cell into a int value
- getValueAsLong(Cell) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
Converts the value bytes of the given cell into a long value
- getValueAsLong(Tag) - Static method in interface org.apache.hadoop.hbase.Tag
-
Converts the value bytes of the given tag into a long value
- getValueAsString(Tag) - Static method in interface org.apache.hadoop.hbase.Tag
-
Converts the value bytes of the given tag into a String value
- getValueBufferShallowCopy(Cell) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
- getValueByteBuffer() - Method in class org.apache.hadoop.hbase.ArrayBackedTag
- getValueByteBuffer() - Method in class org.apache.hadoop.hbase.ByteBufferExtendedCell
-
Returns The
ByteBuffer
containing the value bytes. - getValueByteBuffer() - Method in class org.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValue
- getValueByteBuffer() - Method in class org.apache.hadoop.hbase.ByteBufferKeyValue
- getValueByteBuffer() - Method in class org.apache.hadoop.hbase.ByteBufferTag
- getValueByteBuffer() - Method in interface org.apache.hadoop.hbase.Tag
-
Returns The
ByteBuffer
containing the value bytes. - getValueByteBuffer() - Method in class org.apache.hadoop.hbase.util.MapReduceExtendedCell
- getValueCompressionAlgorithm(Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.wal.CompressionContext
- getValueCompressor() - Method in class org.apache.hadoop.hbase.regionserver.wal.CompressionContext
- getValueFromMBean(ObjectName, String) - Static method in class org.apache.hadoop.hbase.util.JSONMetricUtil
- getValueLength() - Method in class org.apache.hadoop.hbase.ArrayBackedTag
-
Returns Length of actual tag bytes within the backed buffer
- getValueLength() - Method in class org.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValue
- getValueLength() - Method in class org.apache.hadoop.hbase.ByteBufferKeyValue
- getValueLength() - Method in class org.apache.hadoop.hbase.ByteBufferTag
- getValueLength() - Method in interface org.apache.hadoop.hbase.Cell
-
Returns Number of value bytes.
- getValueLength() - Method in class org.apache.hadoop.hbase.IndividualBytesFieldCell
- getValueLength() - Method in class org.apache.hadoop.hbase.KeyValue
-
Returns Value length
- getValueLength() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
- getValueLength() - Method in interface org.apache.hadoop.hbase.Tag
-
Returns Length of tag value within the backed buffer
- getValueLength() - Method in class org.apache.hadoop.hbase.util.MapReduceExtendedCell
- getValueOffset() - Method in class org.apache.hadoop.hbase.ArrayBackedTag
-
Returns Offset of actual tag bytes within the backed buffer
- getValueOffset() - Method in class org.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValue
- getValueOffset() - Method in class org.apache.hadoop.hbase.ByteBufferKeyValue
- getValueOffset() - Method in class org.apache.hadoop.hbase.ByteBufferTag
- getValueOffset() - Method in interface org.apache.hadoop.hbase.Cell
-
Returns Array index of first value byte
- getValueOffset() - Method in class org.apache.hadoop.hbase.IndividualBytesFieldCell
- getValueOffset() - Method in class org.apache.hadoop.hbase.KeyValue
-
Returns the value offset
- getValueOffset() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
- getValueOffset() - Method in interface org.apache.hadoop.hbase.Tag
-
Returns Offset of tag value within the backed buffer
- getValueOffset() - Method in class org.apache.hadoop.hbase.util.MapReduceExtendedCell
- getValuePosition() - Method in class org.apache.hadoop.hbase.ByteBufferExtendedCell
-
Returns Position in the
ByteBuffer
where value bytes start - getValuePosition() - Method in class org.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValue
- getValuePosition() - Method in class org.apache.hadoop.hbase.ByteBufferKeyValue
- getValuePosition() - Method in class org.apache.hadoop.hbase.util.MapReduceExtendedCell
- getValues() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Get all configuration values.
- getValues() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
Returns Getter for fetching an unmodifiable map.
- getValueShallowCopy() - Method in interface org.apache.hadoop.hbase.io.encoding.DataBlockEncoder.EncodedSeeker
-
Does a shallow copy of the value at the current position.
- getValueShallowCopy() - Method in class org.apache.hadoop.hbase.io.encoding.RowIndexSeekerV1
- getValueString(KeyValue) - Static method in class org.apache.hadoop.hbase.KeyValueTestUtil
- getVer(ByteBuffer, ByteBuffer, byte[], byte[], int, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
-
Note: this public interface is slightly different from public Java APIs in regard to handling of the qualifier.
- getVer(ByteBuffer, ByteBuffer, ByteBuffer, int, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
- getVersion() - Method in class org.apache.hadoop.hbase.client.SnapshotDescription
- getVersion() - Method in class org.apache.hadoop.hbase.coprocessor.BaseEnvironment
-
Returns the coprocessor environment version
- getVersion() - Method in interface org.apache.hadoop.hbase.CoprocessorEnvironment
-
Returns the Coprocessor interface version
- getVersion() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.Summary
- getVersion() - Method in class org.apache.hadoop.hbase.regionserver.VersionedSegmentsList
- getVersion() - Method in interface org.apache.hadoop.hbase.ServerMetrics
-
Returns the string type version of a regionserver.
- getVersion() - Static method in class org.apache.hadoop.hbase.util.JvmVersion
-
Return the current JVM version information.
- getVersion() - Static method in class org.apache.hadoop.hbase.util.VersionInfo
-
Get the hbase version.
- getVersion() - Method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp.SetData
- getVersion(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Verifies current version of file system
- getVersion(ServerName) - Method in class org.apache.hadoop.hbase.master.ServerManager
-
May return "0.0.0" when server is not online
- getVersionedBytes() - Method in class org.apache.hadoop.hbase.ServerName
-
Return
ServerName.getServerName()
as bytes with a short-sized prefix with theServerName.VERSION
of this class. - getVersionedList() - Method in class org.apache.hadoop.hbase.regionserver.CompactionPipeline
- getVersionedTail() - Method in class org.apache.hadoop.hbase.regionserver.CompactionPipeline
- getVersionInfo() - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Get a protocol buffer VersionInfo
- getVersionNumber() - Method in interface org.apache.hadoop.hbase.ServerMetrics
-
Returns the version number of a regionserver.
- getVersionNumber(ServerName) - Method in class org.apache.hadoop.hbase.master.ServerManager
-
May return 0 when server is not online.
- getVersionNumber(HBaseProtos.VersionInfo) - Static method in class org.apache.hadoop.hbase.client.VersionInfoUtil
-
Pack the full number version in a int.
- getVersionResource() - Method in class org.apache.hadoop.hbase.rest.RootResource
- getVersionResource() - Method in class org.apache.hadoop.hbase.rest.VersionResource
-
Dispatch /version/rest to self.
- getVerTs(ByteBuffer, ByteBuffer, byte[], byte[], long, int, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
-
Note: this internal interface is slightly different from public APIs in regard to handling of the qualifier.
- getVerTs(ByteBuffer, ByteBuffer, ByteBuffer, long, int, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
- getViolationPolicy() - Method in exception org.apache.hadoop.hbase.quotas.SpaceLimitingException
-
Returns the violation policy in effect.
- getViolationPolicy(QuotaProtos.SpaceQuota) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
- getVisibilityExpressionResolver() - Method in class org.apache.hadoop.hbase.mapreduce.CellCreator
-
Returns Visibility expression resolver
- getVLong() - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
- getVLong() - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
Retrieve the next long value, which is stored as VLong, from this range
- getVLong(int) - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
- getVLong(int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Retrieve the long value at
index
which is stored as VLong - getVLongSize(long) - Static method in class org.apache.hadoop.hbase.util.AbstractByteRange
- getWaitInterval() - Method in exception org.apache.hadoop.hbase.quotas.RpcThrottlingException
- getWaitInterval(long, long, long) - Method in class org.apache.hadoop.hbase.quotas.AverageIntervalRateLimiter
- getWaitInterval(long, long, long) - Method in class org.apache.hadoop.hbase.quotas.FixedIntervalRateLimiter
- getWaitInterval(R, RegionInfo) - Method in interface org.apache.hadoop.hbase.client.AsyncTable.PartialResultCoprocessorCallback
-
Subclasses should implement this such that, when the above method returns non-null, this method returns the duration that AsyncTable should wait before sending the next request to the given region.
- getWaitInterval(R, RegionInfo) - Method in class org.apache.hadoop.hbase.client.NoopPartialResultCoprocessorCallback
- getWaitIntervalMs() - Method in class org.apache.hadoop.hbase.quotas.RateLimiter
-
Is there at least one resource available to allow execution?
- getWaitIntervalMs(long) - Method in class org.apache.hadoop.hbase.quotas.RateLimiter
-
Are there enough available resources to allow execution?
- getWal() - Method in class org.apache.hadoop.hbase.replication.ReplicationGroupOffset
- getWAL() - Method in interface org.apache.hadoop.hbase.coprocessor.WALCoprocessorEnvironment
-
Returns reference to the region server's WAL
- getWAL() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Returns WAL in use for this region
- getWAL() - Method in class org.apache.hadoop.hbase.regionserver.RegionServicesForStores
- getWAL(RegionInfo) - Method in class org.apache.hadoop.hbase.MockRegionServerServices
- getWAL(RegionInfo) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
- getWAL(RegionInfo) - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
Returns the WAL for a particular region.
- getWAL(RegionInfo) - Method in class org.apache.hadoop.hbase.wal.AbstractWALProvider
- getWAL(RegionInfo) - Method in class org.apache.hadoop.hbase.wal.WALFactory
- getWAL(RegionInfo) - Method in interface org.apache.hadoop.hbase.wal.WALProvider
- getWAL0(RegionInfo) - Method in class org.apache.hadoop.hbase.wal.AbstractFSWALProvider
- getWAL0(RegionInfo) - Method in class org.apache.hadoop.hbase.wal.AbstractWALProvider
- getWAL0(RegionInfo) - Method in class org.apache.hadoop.hbase.wal.RegionGroupingProvider
- getWALArchiveDirectoryName(Configuration, String) - Static method in class org.apache.hadoop.hbase.wal.AbstractFSWALProvider
-
Construct the directory name for all old WALs on a given server.
- getWALArchivePath(Path, Path) - Static method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
- getWALBlockSize(Configuration, FileSystem, Path) - Static method in class org.apache.hadoop.hbase.regionserver.wal.WALUtil
-
Blocksize returned here is 2x the default HDFS blocksize unless explicitly set in Configuration.
- getWALBlockSize(Configuration, FileSystem, Path, boolean) - Static method in class org.apache.hadoop.hbase.regionserver.wal.WALUtil
-
Public because of FSHLog.
- getWALCellCodecClass(Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.wal.WALCellCodec
- getWALDirectoryName(String) - Static method in class org.apache.hadoop.hbase.wal.AbstractFSWALProvider
-
Construct the directory name for all WALs on a given server.
- getWALDirPaths(PathFilter) - Method in class org.apache.hadoop.hbase.master.MasterWalManager
-
Returns List of all RegionServer WAL dirs; i.e.
- getWalEdit(int) - Method in class org.apache.hadoop.hbase.regionserver.MiniBatchOperationInProgress
-
Returns Gets the walEdit for the operation(Mutation) at the specified position.
- getWalEditForReplicateIfExistsSkipWAL() - Method in class org.apache.hadoop.hbase.regionserver.MiniBatchOperationInProgress
- getWALEntryfilter() - Method in class org.apache.hadoop.hbase.replication.BaseReplicationEndpoint
-
Returns a default set of filters
- getWALEntryfilter() - Method in interface org.apache.hadoop.hbase.replication.ReplicationEndpoint
-
Returns a WALEntryFilter to use for filtering out WALEntries from the log.
- getWALEntryfilter() - Method in class org.apache.hadoop.hbase.replication.VerifyWALEntriesReplicationEndpoint
- getWALExcludeDNs() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the excluded datanodes in the cache of this region server.
- getWalFactory() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
- getWALFile() - Method in interface org.apache.hadoop.hbase.coordination.SplitLogWorkerCoordination.SplitTaskDetails
-
Deprecated.Returns full file path in HDFS for the WAL file to be split.
- getWALFile() - Method in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination.ZkSplitTaskDetails
- getWALFileLengthProvider() - Method in interface org.apache.hadoop.hbase.wal.WALProvider
- getWALFiles(Configuration, ServerName) - Static method in class org.apache.hadoop.hbase.wal.AbstractFSWALProvider
-
List all the wal files for a logPrefix.
- getWALFileSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the size of WAL files of this region server.
- getWALFileSystem() - Method in class org.apache.hadoop.hbase.HBaseServerBase
-
Returns Return the walFs.
- getWALFileSystem() - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
- getWALFileSystem(Configuration) - Static method in class org.apache.hadoop.hbase.util.CommonFSUtils
- getWalGroupId() - Method in class org.apache.hadoop.hbase.replication.ReplicationEndpoint.ReplicateContext
- getWalGroupsReplicationStatus() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
- getWalLength() - Method in class org.apache.hadoop.hbase.namequeues.WALEventTrackerPayload
- getWalName() - Method in class org.apache.hadoop.hbase.namequeues.WALEventTrackerPayload
- getWALObserver() - Method in interface org.apache.hadoop.hbase.coprocessor.WALCoprocessor
- getWalOffsets() - Method in class org.apache.hadoop.hbase.replication.ZKReplicationQueueStorageForMigration.ZkReplicationQueueData
- getWalPath() - Method in class org.apache.hadoop.hbase.regionserver.SplitWALCallable
- getWALPrefixFromWALName(String) - Static method in class org.apache.hadoop.hbase.wal.AbstractFSWALProvider
-
Get prefix of the log from its name, assuming WAL name in format of log_prefix.filenumber.log_suffix
- getWALProvider() - Method in class org.apache.hadoop.hbase.wal.WALFactory
- getWALRegionDir() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
- getWALRegionDir(Configuration, TableName, String) - Static method in class org.apache.hadoop.hbase.util.CommonFSUtils
-
Returns the WAL region directory based on the given table name and region name
- getWalRoller() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
- getWALRootDir() - Method in class org.apache.hadoop.hbase.HBaseServerBase
-
Returns Return the walRootDir.
- getWALRootDir() - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
-
Returns HBase root log dir.
- getWALRootDir(Configuration) - Static method in class org.apache.hadoop.hbase.util.CommonFSUtils
-
Get the path for the root directory for WAL data
- getWALs() - Method in class org.apache.hadoop.hbase.MockRegionServerServices
- getWALs() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
- getWALs() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
Returns the List of WALs that are used by this server Doesn't include the meta WAL
- getWALs() - Method in class org.apache.hadoop.hbase.wal.AbstractWALProvider
- getWALs() - Method in class org.apache.hadoop.hbase.wal.WALFactory
- getWALs() - Method in interface org.apache.hadoop.hbase.wal.WALProvider
-
Returns the List of WALs that are used by this server
- getWALs0() - Method in class org.apache.hadoop.hbase.wal.AbstractFSWALProvider
- getWALs0() - Method in class org.apache.hadoop.hbase.wal.AbstractWALProvider
- getWALs0() - Method in class org.apache.hadoop.hbase.wal.RegionGroupingProvider
- getWALsToSplit(ServerName, boolean) - Method in class org.apache.hadoop.hbase.master.SplitWALManager
- getWALTableDir(Configuration, TableName) - Static method in class org.apache.hadoop.hbase.util.CommonFSUtils
-
Returns the Table directory under the WALRootDir for the specified table name
- getWatcher() - Method in class org.apache.hadoop.hbase.zookeeper.ZKListener
-
Returns The watcher associated with this listener
- getWebAppContext() - Method in class org.apache.hadoop.hbase.http.HttpServer
- getWebAppsPath(String) - Method in class org.apache.hadoop.hbase.http.HttpServer
- getWebAppsPath(String, String) - Method in class org.apache.hadoop.hbase.http.HttpServer
-
Get the pathname to the webapps files.
- getWeight() - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution.HostAndWeight
-
Returns the weight
- getWeight(String) - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution
-
return the weight for a specific host, that will be the total bytes of all blocks on the host
- getWeightForSsd() - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution.HostAndWeight
-
Returns the weight for ssd
- getWorkers() - Method in class org.apache.hadoop.hbase.backup.BackupInfo
- getWorkingSnapshotDir(String, Path, Configuration) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
Get the directory to build a snapshot, before it is finalized
- getWorkingSnapshotDir(Path, Configuration) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
Get the general working directory for snapshots - where they are built, where they are temporarily copied on export, etc.
- getWorkingSnapshotDir(SnapshotProtos.SnapshotDescription, Path, Configuration) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
Get the directory to build a snapshot, before it is finalized
- getWrapper() - Method in class org.apache.hadoop.hbase.io.MetricsIO
- getWritable(byte[], int, int, Writable) - Static method in class org.apache.hadoop.hbase.util.Writables
-
Set bytes into the passed Writable by calling its
Writable.readFields(java.io.DataInput)
. - getWritable(byte[], Writable) - Static method in class org.apache.hadoop.hbase.util.Writables
-
Set bytes into the passed Writable by calling its
Writable.readFields(java.io.DataInput)
. - getWritableSize() - Method in interface org.apache.hadoop.hbase.io.WritableWithSize
-
Provide a size hint to the caller.
- getWriteAvailable() - Method in interface org.apache.hadoop.hbase.quotas.QuotaLimiter
-
Returns the number of bytes available to write to avoid exceeding the quota
- getWriteAvailable() - Method in class org.apache.hadoop.hbase.quotas.TimeBasedLimiter
- getWriteBufferFatalThreshold() - Method in class org.apache.hadoop.hbase.ipc.NettyRpcServer
- getWriteBufferPeriodicFlushTimeoutMs() - Method in interface org.apache.hadoop.hbase.client.BufferedMutator
-
Returns the current periodic flush timeout value in milliseconds.
- getWriteBufferPeriodicFlushTimeoutMs() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
- getWriteBufferPeriodicFlushTimeoutMs() - Method in class org.apache.hadoop.hbase.client.ConnectionConfiguration
- getWriteBufferPeriodicFlushTimerTickMs() - Method in interface org.apache.hadoop.hbase.client.BufferedMutator
-
Returns the current periodic flush timertick interval in milliseconds.
- getWriteBufferPeriodicFlushTimerTickMs() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
-
Deprecated.Since 3.0.0, will be removed in 4.0.0. We use a common timer in the whole client implementation so you can not set it any more.
- getWriteBufferPeriodicFlushTimerTickMs() - Method in class org.apache.hadoop.hbase.client.ConnectionConfiguration
- getWriteBufferSize() - Method in interface org.apache.hadoop.hbase.client.AsyncBufferedMutator
-
Returns the maximum size in bytes of the write buffer.
- getWriteBufferSize() - Method in interface org.apache.hadoop.hbase.client.BufferedMutator
-
Returns the maximum size in bytes of the write buffer for this HTable.
- getWriteBufferSize() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
- getWriteBufferSize() - Method in class org.apache.hadoop.hbase.client.ConnectionConfiguration
- getWriteEntry() - Method in class org.apache.hadoop.hbase.wal.WALKeyImpl
-
Use it to complete mvcc transaction.
- getWriteLimit() - Method in interface org.apache.hadoop.hbase.quotas.QuotaLimiter
-
Returns the maximum number of bytes ever available to write
- getWriteLimit() - Method in class org.apache.hadoop.hbase.quotas.TimeBasedLimiter
- getWriteNumber() - Method in class org.apache.hadoop.hbase.regionserver.MultiVersionConcurrencyControl.WriteEntry
- getWriteNumLimit() - Method in interface org.apache.hadoop.hbase.quotas.QuotaLimiter
-
Returns the maximum number of writes to allow per TimeUnit
- getWriteNumLimit() - Method in class org.apache.hadoop.hbase.quotas.TimeBasedLimiter
- getWritePoint() - Method in class org.apache.hadoop.hbase.regionserver.MultiVersionConcurrencyControl
- getWriteQueueLength() - Method in class org.apache.hadoop.hbase.ipc.DelegatingRpcScheduler
- getWriteQueueLength() - Method in class org.apache.hadoop.hbase.ipc.FifoRpcScheduler
- getWriteQueueLength() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapper
- getWriteQueueLength() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapperImpl
- getWriteQueueLength() - Method in class org.apache.hadoop.hbase.ipc.RpcExecutor
- getWriteQueueLength() - Method in class org.apache.hadoop.hbase.ipc.RpcScheduler
-
Retrieves length of the write queue for metrics when use RWQueueRpcExecutor.
- getWriteQueueLength() - Method in class org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
- getWriteQueueLength() - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
- getWriterClsNames() - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractProtobufWALReader
-
Returns names of the accepted writer classes
- getWriteRequestCount() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
Returns the number of write requests made to region
- getWriteRequestCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
-
Get the total number of mutations that have been issued against this region.
- getWriteRequestCount() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
- getWriteRequestCount() - Method in interface org.apache.hadoop.hbase.UserMetrics
-
Returns the number of write requests made by user
- getWriteRequestCount(String) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregate
-
Get the number of write requests that have been issued for this table
- getWriteRequestCount(String) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImpl
- getWriteRequestCountPerSecond() - Method in class org.apache.hadoop.hbase.hbtop.mode.RequestCountPerSecond
- getWriteRequestsCount() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
- getWriteRequestsCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the number of write requests to regions hosted on this region server.
- getWriteRequestsCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsUserSource.ClientMetrics
- getWriteRequestsCount() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Returns write request count for this region
- getWriteRequestsCount() - Method in interface org.apache.hadoop.hbase.ServerMetrics
-
Returns total Number of write requests from the start of the region server.
- getWriteRequestsCount() - Method in interface org.apache.hadoop.hbase.UserMetrics.ClientMetrics
- getWriteRequestsCount() - Method in class org.apache.hadoop.hbase.UserMetricsBuilder.ClientMetricsImpl
- getWriteRequestsRatePerSecond() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the rate of write requests per second to regions hosted on this region server.
- getWriterFactory(Configuration, CacheConfig) - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
-
Returns the factory to be used to create
HFile
writers - getWriterFactoryNoCache(Configuration) - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
-
Returns the factory to be used to create
HFile
writers. - getWriteRpcTimeout() - Method in class org.apache.hadoop.hbase.client.ConnectionConfiguration
- getWriteRpcTimeout(TimeUnit) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
Get timeout of each rpc write request in this Table instance.
- getWriteRpcTimeout(TimeUnit) - Method in interface org.apache.hadoop.hbase.client.Table
-
Get timeout of each rpc write request in this Table instance.
- getWriteTime() - Method in interface org.apache.hadoop.hbase.wal.WALKey
-
Returns the write time
- getWriteTime() - Method in class org.apache.hadoop.hbase.wal.WALKeyImpl
-
Returns the write time
- getWrongWALRegionDir(Configuration, TableName, String) - Static method in class org.apache.hadoop.hbase.util.CommonFSUtils
-
Deprecated.For compatibility, will be removed in 4.0.0.
- getYarnPoolName() - Method in class org.apache.hadoop.hbase.backup.BackupRequest
- getZeroCopyBytesRead() - Static method in class org.apache.hadoop.hbase.io.FSDataInputStreamWrapper
- getZeroCopyBytesRead() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Returns Number of bytes read locally through HDFS zero copy.
- getZKClientConfig(Configuration) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKConfig
- getZkCluster() - Method in class org.apache.hadoop.hbase.HBaseZKTestingUtility
-
Deprecated.
- getZkConnectionURI() - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- getZkPermissionWatcher() - Method in class org.apache.hadoop.hbase.HBaseRpcServicesBase
- getZKPermissionWatcher() - Method in class org.apache.hadoop.hbase.HBaseServerBase
- getZKPermissionWatcher() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Returns the
ZKPermissionWatcher
- getZKPermissionWatcher() - Method in class org.apache.hadoop.hbase.MockRegionServerServices
- getZKPermissionWatcher() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
Returns
ZKPermissionWatcher
- getZKQuorum(Configuration) - Static method in class org.apache.hadoop.hbase.chaos.ChaosUtils
- getZKQuorumServersString(Configuration) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKConfig
-
Return the ZK Quorum servers string given the specified configuration.
- getZNodeForReplica(int) - Method in class org.apache.hadoop.hbase.zookeeper.ZNodePaths
-
Returns the znode string corresponding to a replicaId
- getZnodeParent() - Method in class org.apache.hadoop.hbase.zookeeper.ZKConfig.ZKClusterKey
- getZNodePaths() - Method in class org.apache.hadoop.hbase.zookeeper.ZKWatcher
-
Get the znodePaths.
- getZooKeeper() - Method in class org.apache.hadoop.hbase.HBaseServerBase
- getZooKeeper() - Method in class org.apache.hadoop.hbase.MockRegionServerServices
- getZooKeeper() - Method in interface org.apache.hadoop.hbase.Server
-
Gets the ZooKeeper instance for this server.
- getZooKeeper() - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
- getZooKeeperClusterKey(Configuration) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKConfig
-
Get the key to the ZK ensemble for this configuration without adding a name at the end
- getZooKeeperClusterKey(Configuration, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKConfig
-
Get the key to the ZK ensemble for this configuration and append a name at the end
- getZookeeperQuorum() - Method in interface org.apache.hadoop.hbase.master.MetricsMasterWrapper
-
Get the ZooKeeper Quorum Info
- getZookeeperQuorum() - Method in class org.apache.hadoop.hbase.master.MetricsMasterWrapperImpl
- getZookeeperQuorum() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the ZooKeeper Quorum Info
- getZooKeeperServerNum() - Method in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
- getZooKeeperWatcher() - Method in class org.apache.hadoop.hbase.HBaseZKTestingUtility
-
Deprecated.Returns a ZKWatcher instance.
- getZooKeeperWatcher(HBaseZKTestingUtility) - Static method in class org.apache.hadoop.hbase.HBaseZKTestingUtility
-
Deprecated.Gets a ZKWatcher.
- GIGABYTE - Enum constant in enum class org.apache.hadoop.hbase.Size.Unit
- global() - Static method in class org.apache.hadoop.hbase.metrics.MetricRegistries
-
Return the global singleton instance for the MetricRegistries.
- GLOBAL_BYPASS - Enum constant in enum class org.apache.hadoop.hbase.quotas.QuotaType
- globalLimiter - Variable in class org.apache.hadoop.hbase.quotas.QuotaState
- org.apache.hadoop.hbase.quotas.GlobalQuotaSettings - Class in org.apache.hadoop.hbase.quotas
-
An object which captures all quotas types (throttle or space) for a subject (user, table, or namespace).
- GlobalQuotaSettings(String, TableName, String, String) - Constructor for class org.apache.hadoop.hbase.quotas.GlobalQuotaSettings
- org.apache.hadoop.hbase.quotas.GlobalQuotaSettingsImpl - Class in org.apache.hadoop.hbase.quotas
-
Implementation of
GlobalQuotaSettings
to hide the Protobuf messages we use internally. - GlobalQuotaSettingsImpl(String, TableName, String, String, QuotaProtos.Quotas) - Constructor for class org.apache.hadoop.hbase.quotas.GlobalQuotaSettingsImpl
- GlobalQuotaSettingsImpl(String, TableName, String, String, QuotaProtos.Throttle, Boolean, QuotaProtos.SpaceQuota) - Constructor for class org.apache.hadoop.hbase.quotas.GlobalQuotaSettingsImpl
- goToFilterDisplayMode(Screen, Terminal, int) - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenPresenter
- goToInputModeForFilter(Screen, Terminal, int, boolean) - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenPresenter
- goToInputModeForRefreshDelay(Screen, Terminal, int) - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenPresenter
- goToMessageMode(Screen, Terminal, int, String) - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenPresenter
- grabQuota(long, long, long, long, long, long) - Method in interface org.apache.hadoop.hbase.quotas.QuotaLimiter
-
Removes the specified write and read amount from the quota.
- grabQuota(long, long, long, long, long, long) - Method in class org.apache.hadoop.hbase.quotas.TimeBasedLimiter
- grant(UserPermission, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Grants user specific permissions
- grant(UserPermission, boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Grants user specific permissions
- grant(TAccessControlEntity) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
- grant(RpcController, AccessControlProtos.GrantRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- greater(Object) - Method in class org.apache.hadoop.hbase.hbtop.RecordFilter.FilterBuilder
- greater(FieldValue) - Method in class org.apache.hadoop.hbase.hbtop.RecordFilter.FilterBuilder
- GREATER - Enum constant in enum class org.apache.hadoop.hbase.CompareOperator
-
greater than
- GREATER_OR_EQUAL - Enum constant in enum class org.apache.hadoop.hbase.CompareOperator
-
greater than or equal to
- GREATER_THAN_ARRAY - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
GREATER_THAN Array
- GREATER_THAN_BUFFER - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
- GREATER_THAN_OR_EQUAL_TO_ARRAY - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
GREATER_THAN_OR_EQUAL_TO Array
- GREATER_THAN_OR_EQUAL_TO_BUFFER - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
- greaterOrEqual(Object) - Method in class org.apache.hadoop.hbase.hbtop.RecordFilter.FilterBuilder
- greaterOrEqual(FieldValue) - Method in class org.apache.hadoop.hbase.hbtop.RecordFilter.FilterBuilder
- GREEN - Enum constant in enum class org.apache.hadoop.hbase.hbtop.terminal.Color
- group() - Method in class org.apache.hadoop.hbase.util.NettyEventLoopGroupConfig
- group(byte[], byte[]) - Method in class org.apache.hadoop.hbase.wal.BoundedGroupingStrategy
- group(byte[], byte[]) - Method in class org.apache.hadoop.hbase.wal.NamespaceGroupingStrategy
- group(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.wal.RegionGroupingProvider.RegionGroupingStrategy
-
Given an identifier and a namespace, pick a group.
- GROUP_COLUMNS - Static variable in class org.apache.hadoop.hbase.mapred.GroupingTableMap
-
JobConf parameter to specify the columns used to produce the key passed to collect from the map phase
- GROUP_COLUMNS - Static variable in class org.apache.hadoop.hbase.mapreduce.GroupingTableMapper
-
JobConf parameter to specify the columns used to produce the key passed to collect from the map phase.
- GROUP_NAME_DELIMITER - Static variable in interface org.apache.hadoop.hbase.wal.RegionGroupingProvider.RegionGroupingStrategy
- org.apache.hadoop.hbase.mapred.GroupingTableMap - Class in org.apache.hadoop.hbase.mapred
-
Extract grouping columns from input record
- GroupingTableMap() - Constructor for class org.apache.hadoop.hbase.mapred.GroupingTableMap
- org.apache.hadoop.hbase.mapreduce.GroupingTableMapper - Class in org.apache.hadoop.hbase.mapreduce
-
Extract grouping columns from input record.
- GroupingTableMapper() - Constructor for class org.apache.hadoop.hbase.mapreduce.GroupingTableMapper
- GSON - Static variable in class org.apache.hadoop.hbase.ipc.RpcServer
- org.apache.hadoop.hbase.http.gson.GsonMessageBodyWriter<T> - Class in org.apache.hadoop.hbase.http.gson
-
Implements JSON serialization via
Gson
for JAX-RS. - GsonMessageBodyWriter(Gson) - Constructor for class org.apache.hadoop.hbase.http.gson.GsonMessageBodyWriter
- org.apache.hadoop.hbase.util.GsonUtil - Class in org.apache.hadoop.hbase.util
-
Helper class for gson.
- GZ - Enum constant in enum class org.apache.hadoop.hbase.io.compress.Compression.Algorithm
- GZ_CODEC_CLASS_DEFAULT - Static variable in class org.apache.hadoop.hbase.io.compress.Compression
- GZ_CODEC_CLASS_KEY - Static variable in class org.apache.hadoop.hbase.io.compress.Compression
H
- H - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
ASCII code for 'H'
- HADOOP_DOMAIN - Static variable in class org.apache.hadoop.hbase.util.JSONMetricUtil
- org.apache.hadoop.hbase.io.HalfStoreFileReader - Class in org.apache.hadoop.hbase.io
-
A facade for a
HFile.Reader
that serves up either the top or bottom half of a HFile where 'bottom' is the first half of the file containing the keys that sort lowest and 'top' is the second half of the file with keys that sort greater than those of the bottom half. - HalfStoreFileReader(ReaderContext, HFileInfo, CacheConfig, Reference, StoreFileInfo, Configuration) - Constructor for class org.apache.hadoop.hbase.io.HalfStoreFileReader
-
Creates a half file reader for a hfile referred to by an hfilelink.
- handleCoprocessorThrowable(E, Throwable) - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
-
This is used by coprocessor hooks which are declared to throw IOException (or its subtypes).
- handleDegenerateRegion(HbckRegionInfo) - Method in interface org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandler
-
Callback for handling a region that has the same start and end key.
- handleDegenerateRegion(HbckRegionInfo) - Method in class org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandlerImpl
-
Callback for handling a region that has the same start and end key.
- handleDuplicateStartKeys(HbckRegionInfo, HbckRegionInfo) - Method in interface org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandler
-
Callback for handling two regions that have the same start key.
- handleDuplicateStartKeys(HbckRegionInfo, HbckRegionInfo) - Method in class org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandlerImpl
-
Callback for handling two regions that have the same start key.
- handleHoleInRegionChain(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandler
-
Callback for handling a region hole between two keys.
- handleHoleInRegionChain(byte[], byte[]) - Method in class org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandlerImpl
-
Callback for handling a region hole between two keys.
- handleKeyPress(KeyPress) - Method in class org.apache.hadoop.hbase.hbtop.screen.AbstractScreenView
- handleKeyPress(KeyPress) - Method in class org.apache.hadoop.hbase.hbtop.screen.field.FieldScreenView
- handleKeyPress(KeyPress) - Method in class org.apache.hadoop.hbase.hbtop.screen.help.HelpScreenView
- handleKeyPress(KeyPress) - Method in class org.apache.hadoop.hbase.hbtop.screen.mode.ModeScreenView
- handleKeyPress(KeyPress) - Method in interface org.apache.hadoop.hbase.hbtop.screen.ScreenView
- handleKeyPress(KeyPress) - Method in class org.apache.hadoop.hbase.hbtop.screen.top.FilterDisplayModeScreenView
- handleKeyPress(KeyPress) - Method in class org.apache.hadoop.hbase.hbtop.screen.top.InputModeScreenView
- handleKeyPress(KeyPress) - Method in class org.apache.hadoop.hbase.hbtop.screen.top.MessageModeScreenView
- handleKeyPress(KeyPress) - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenView
- handleOverlapGroup(Collection<HbckRegionInfo>) - Method in interface org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandler
-
Callback for handling an group of regions that overlap.
- handleOverlapGroup(Collection<HbckRegionInfo>) - Method in class org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandlerImpl
-
Callback for handling an group of regions that overlap.
- handleOverlapInRegionChain(HbckRegionInfo, HbckRegionInfo) - Method in interface org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandler
-
Callback for handling two reigons that overlap in some arbitrary way.
- handleOverlapInRegionChain(HbckRegionInfo, HbckRegionInfo) - Method in class org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandlerImpl
-
Callback for handling two reigons that overlap in some arbitrary way.
- HANDLER_NAME - Static variable in class org.apache.hadoop.hbase.security.NettyHBaseSaslRpcClientHandler
- handlerAdded(ChannelHandlerContext) - Method in class org.apache.hadoop.hbase.security.NettyHBaseRpcConnectionHeaderHandler
- handlerAdded(ChannelHandlerContext) - Method in class org.apache.hadoop.hbase.security.NettyHBaseSaslRpcClientHandler
- handlerCount - Variable in class org.apache.hadoop.hbase.ipc.FifoRpcScheduler
- handleRegionEndKeyNotEmpty(byte[]) - Method in interface org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandler
-
Callback for handling case where a Table has a last region that does not have an empty end key.
- handleRegionEndKeyNotEmpty(byte[]) - Method in class org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandlerImpl
-
Callback for handling case where a Table has a last region that does not have an empty end key.
- handleRegionStartKeyNotEmpty(HbckRegionInfo) - Method in interface org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandler
-
Callback for handling case where a Table has a first region that does not have an empty start key.
- handleRegionStartKeyNotEmpty(HbckRegionInfo) - Method in class org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandlerImpl
-
Callback for handling case where a Table has a first region that does not have an empty start key.
- handleRemoteException(Throwable) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Like
ProtobufUtil.getRemoteException(ServiceException)
but more generic, able to handle more than justServiceException
. - handleReportForDutyResponse(RegionServerStatusProtos.RegionServerStartupResponse) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster.MiniHBaseClusterRegionServer
-
Deprecated.
- handleReportForDutyResponse(RegionServerStatusProtos.RegionServerStartupResponse) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Run init.
- handleSplit(HbckRegionInfo, HbckRegionInfo) - Method in interface org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandler
-
Callback for handling two regions that have the same regionID a specific case of a split
- handleTimer() - Method in class org.apache.hadoop.hbase.hbtop.screen.AbstractScreenView
- handleTimer() - Method in interface org.apache.hadoop.hbase.hbtop.screen.ScreenView
- handleTimer() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.MessageModeScreenView
- handleTimer() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenView
- has(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Mutation
-
A convenience method to determine if this object's familyMap contains a value assigned to the given family & qualifier.
- has(byte[], byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Mutation
-
A convenience method to determine if this object's familyMap contains a value assigned to the given family, qualifier and timestamp.
- has(byte[], byte[], long) - Method in class org.apache.hadoop.hbase.client.Mutation
-
A convenience method to determine if this object's familyMap contains a value assigned to the given family, qualifier and timestamp.
- has(byte[], byte[], long, byte[]) - Method in class org.apache.hadoop.hbase.client.Mutation
-
A convenience method to determine if this object's familyMap contains the given value assigned to the given family, qualifier and timestamp.
- has(byte[], byte[], long, byte[], boolean, boolean) - Method in class org.apache.hadoop.hbase.client.Mutation
-
Private method to determine if this object's familyMap contains the given value assigned to the given family, qualifier and timestamp, respecting the 2 boolean arguments.
- HAS_LARGE_RESULT - Static variable in class org.apache.hadoop.hbase.mapreduce.Import
- hasAdministratorAccess(ServletContext, HttpServletRequest, HttpServletResponse) - Static method in class org.apache.hadoop.hbase.http.HttpServer
-
Does the user sending the HttpServletRequest has the administrator ACLs? If it isn't the case, response will be modified to send an error to the user.
- hasAdministratorAccess(Configuration, AccessControlList, HttpServletRequest, HttpServletResponse) - Static method in class org.apache.hadoop.hbase.http.HttpServer
- hasArray() - Method in class org.apache.hadoop.hbase.ArrayBackedTag
- hasArray() - Method in class org.apache.hadoop.hbase.ByteBufferTag
- hasArray() - Method in class org.apache.hadoop.hbase.nio.ByteBuff
-
Returns true or false if the underlying BB support hasArray
- hasArray() - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
Returns false.
- hasArray() - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
- hasArray() - Method in interface org.apache.hadoop.hbase.Tag
-
Return true if the tag is backed by a byte array
- hasAttributes() - Method in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
- hasBody() - Method in class org.apache.hadoop.hbase.rest.client.Response
-
Returns true if a response body was sent
- hasBulkloadSeqId(Path) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
- hasBypassGlobals() - Method in class org.apache.hadoop.hbase.quotas.UserQuotaState
- hasCallTimeout() - Method in class org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
- hasCallTimeout() - Method in interface org.apache.hadoop.hbase.ipc.HBaseRpcController
- hasCallTimeout() - Method in class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
- hasCellBlockSupport() - Method in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
- hasCellBlockSupport() - Method in interface org.apache.hadoop.hbase.ipc.RpcClient
-
Return true when this client uses a
Codec
and so supports cell blocks. - hasCellTTL() - Method in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
- hasCellVisibility() - Method in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
- hasColumnFamily(byte[]) - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
Checks to see if this table contains the given column family
- hasColumns() - Method in class org.apache.hadoop.hbase.rest.RowSpec
- hasCompression - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractProtobufWALReader
- hasConsumerTask - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
- hasCoprocessor(String) - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
Check if the table has an attached co-processor represented by the name className
- hasCoprocessor(String) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
- hasCustomPostScannerFilterRow() - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
- hasData() - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueueStorage
-
Whether the replication queue table exists.
- hasData() - Method in class org.apache.hadoop.hbase.replication.TableReplicationQueueStorage
- hasData() - Method in class org.apache.hadoop.hbase.replication.ZKReplicationQueueStorageForMigration
- hasEditsSinceRestart() - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSource
- hasEncodedName(byte[]) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Does region name contain its encoded name?
- hasEndRow() - Method in class org.apache.hadoop.hbase.rest.RowSpec
- hasException() - Method in class org.apache.hadoop.hbase.errorhandling.ForeignExceptionDispatcher
- hasException() - Method in interface org.apache.hadoop.hbase.errorhandling.ForeignExceptionSnare
-
Non-exceptional form of
ForeignExceptionSnare.rethrowException()
. - hasException() - Method in class org.apache.hadoop.hbase.zookeeper.DeletionListener
-
Check if an exception has occurred when re-setting the watch.
- hasFamilies() - Method in class org.apache.hadoop.hbase.client.Get
-
Method for checking if any families have been inserted into this Get
- hasFamilies() - Method in class org.apache.hadoop.hbase.client.ImmutableScan
- hasFamilies() - Method in class org.apache.hadoop.hbase.client.Increment
-
Method for checking if any families have been inserted into this Increment
- hasFamilies() - Method in class org.apache.hadoop.hbase.client.Scan
-
Returns true if familyMap is non empty, false otherwise
- hasFamilyStamp - Variable in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanDeleteTracker
- hasFilter() - Method in class org.apache.hadoop.hbase.client.CheckAndMutate
-
Returns whether this has a filter or not
- hasFilter() - Method in class org.apache.hadoop.hbase.client.ImmutableScan
- hasFilter() - Method in class org.apache.hadoop.hbase.client.Scan
-
Returns true is a filter has been specified, false if not
- hasFilterRow() - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
- hasFilterRow() - Method in class org.apache.hadoop.hbase.filter.Filter
-
Primarily used to check for conflicts with scans(such as scans that do not read a full row at a time).
- hasFilterRow() - Method in class org.apache.hadoop.hbase.filter.FilterAllFilter
- hasFilterRow() - Method in class org.apache.hadoop.hbase.filter.FilterBase
-
Filters that never filter by modifying the returned List of Cells can inherit this implementation that does nothing.
- hasFilterRow() - Method in class org.apache.hadoop.hbase.filter.FilterList
- hasFilterRow() - Method in class org.apache.hadoop.hbase.filter.FilterListBase
- hasFilterRow() - Method in class org.apache.hadoop.hbase.filter.FilterWrapper
- hasFilterRow() - Method in class org.apache.hadoop.hbase.filter.PageFilter
- hasFilterRow() - Method in class org.apache.hadoop.hbase.filter.RandomRowFilter
- hasFilterRow() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter
- hasFilterRow() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
- hasFilterRow() - Method in class org.apache.hadoop.hbase.filter.SkipFilter
- hasFilterRow() - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
- hasFoundKV() - Method in class org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
-
Returns true if first KV has been found.
- hasGeneralBloom() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileWriter
- hasGlobalReplicationScope() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
Check if any of the table's cfs' replication scope are set to
HConstants.REPLICATION_SCOPE_GLOBAL
. - hash - Variable in class org.apache.hadoop.hbase.util.AbstractByteRange
-
Variable for lazy-caching the hashCode of this range.
- hash - Variable in class org.apache.hadoop.hbase.util.BloomFilterChunk
-
Hash Function
- hash(HashKey<T>, int) - Method in class org.apache.hadoop.hbase.util.Hash
-
Calculate a hash using bytes from HashKey and the provided seed value.
- hash(HashKey<T>, int) - Method in class org.apache.hadoop.hbase.util.JenkinsHash
-
taken from hashlittle() -- hash a variable-length key into a 32-bit value
- hash(HashKey<T>, int) - Method in class org.apache.hadoop.hbase.util.MurmurHash
- hash(HashKey<T>, int) - Method in class org.apache.hadoop.hbase.util.MurmurHash3
-
Returns the MurmurHash3_x86_32 hash.
- org.apache.hadoop.hbase.util.Hash - Class in org.apache.hadoop.hbase.util
-
This class represents a common API for hashing functions.
- Hash() - Constructor for class org.apache.hadoop.hbase.util.Hash
- HASH - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregate
- HASH_NONCE_GRACE_PERIOD_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.ServerNonceManager
- hash128(byte[]...) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
-
Return the MD5 digest of the concatenation of the supplied arguments.
- hash128(String...) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
-
Return the MD5 digest of the concatenation of the supplied arguments.
- hash256(byte[]...) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
-
Return the SHA-256 digest of the concatenation of the supplied arguments.
- hash256(String...) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
-
Return the SHA-256 digest of the concatenation of the supplied arguments.
- hashCode() - Method in class org.apache.hadoop.hbase.backup.BackupInfo
- hashCode() - Method in class org.apache.hadoop.hbase.ByteBufferKeyValue
-
In line with
ByteBufferKeyValue.equals(Object)
, only uses the key portion, not the value. - hashCode() - Method in class org.apache.hadoop.hbase.client.Action
- hashCode() - Method in class org.apache.hadoop.hbase.client.Get
- hashCode() - Method in class org.apache.hadoop.hbase.client.LogQueryFilter
-
Deprecated.
- hashCode() - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord
- hashCode() - Method in class org.apache.hadoop.hbase.client.RegionCoprocessorServiceExec
- hashCode() - Method in class org.apache.hadoop.hbase.client.RegionStatesCount
- hashCode() - Method in class org.apache.hadoop.hbase.client.SlowLogParams
- hashCode() - Method in class org.apache.hadoop.hbase.client.TableState
- hashCode() - Method in class org.apache.hadoop.hbase.favored.FavoredNodesPlan
- hashCode() - Method in class org.apache.hadoop.hbase.filter.BigDecimalComparator
- hashCode() - Method in class org.apache.hadoop.hbase.filter.BinaryComponentComparator
- hashCode() - Method in class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
- hashCode() - Method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
- hashCode() - Method in class org.apache.hadoop.hbase.filter.ColumnPrefixFilter
- hashCode() - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
- hashCode() - Method in class org.apache.hadoop.hbase.filter.ColumnValueFilter
- hashCode() - Method in class org.apache.hadoop.hbase.filter.CompareFilter
- hashCode() - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
- hashCode() - Method in class org.apache.hadoop.hbase.filter.FamilyFilter
- hashCode() - Method in class org.apache.hadoop.hbase.filter.FilterList
- hashCode() - Method in class org.apache.hadoop.hbase.filter.FilterListWithAND
- hashCode() - Method in class org.apache.hadoop.hbase.filter.FilterListWithOR
- hashCode() - Method in class org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
- hashCode() - Method in class org.apache.hadoop.hbase.filter.FuzzyRowFilter
- hashCode() - Method in class org.apache.hadoop.hbase.filter.InclusiveStopFilter
- hashCode() - Method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter
- hashCode() - Method in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
- hashCode() - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.RowRange
- hashCode() - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter
- hashCode() - Method in class org.apache.hadoop.hbase.filter.NullComparator
- hashCode() - Method in class org.apache.hadoop.hbase.filter.PageFilter
- hashCode() - Method in class org.apache.hadoop.hbase.filter.PrefixFilter
- hashCode() - Method in class org.apache.hadoop.hbase.filter.QualifierFilter
- hashCode() - Method in class org.apache.hadoop.hbase.filter.RandomRowFilter
- hashCode() - Method in class org.apache.hadoop.hbase.filter.RowFilter
- hashCode() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter
- hashCode() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
- hashCode() - Method in class org.apache.hadoop.hbase.filter.SkipFilter
- hashCode() - Method in class org.apache.hadoop.hbase.filter.TimestampsFilter
- hashCode() - Method in class org.apache.hadoop.hbase.filter.ValueFilter
- hashCode() - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
- hashCode() - Method in class org.apache.hadoop.hbase.hbtop.field.FieldValue
- hashCode() - Method in class org.apache.hadoop.hbase.hbtop.RecordFilter
- hashCode() - Method in class org.apache.hadoop.hbase.hbtop.terminal.Attributes
- hashCode() - Method in class org.apache.hadoop.hbase.hbtop.terminal.CursorPosition
- hashCode() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.Cell
- hashCode() - Method in class org.apache.hadoop.hbase.hbtop.terminal.TerminalSize
- hashCode() - Method in class org.apache.hadoop.hbase.HRegionLocation
- hashCode() - Method in class org.apache.hadoop.hbase.io.FileLink
- hashCode() - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheKey
- hashCode() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
- hashCode() - Method in class org.apache.hadoop.hbase.io.hfile.HFileInfo
- hashCode() - Method in class org.apache.hadoop.hbase.io.hfile.LruCachedBlock
- hashCode() - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
- hashCode() - Method in class org.apache.hadoop.hbase.io.Reference
- hashCode() - Method in class org.apache.hadoop.hbase.JitterScheduledThreadPoolExecutorImpl.JitteredRunnableScheduledFuture
- hashCode() - Method in class org.apache.hadoop.hbase.KeyValue
-
In line with
KeyValue.equals(Object)
, only uses the key portion, not the value. - hashCode() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
- hashCode() - Method in class org.apache.hadoop.hbase.mapred.TableSplit
- hashCode() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
- hashCode() - Method in class org.apache.hadoop.hbase.master.RegionPlan
- hashCode() - Method in class org.apache.hadoop.hbase.master.RegionState
-
Don't count timestamp in hash code calculation
- hashCode() - Method in class org.apache.hadoop.hbase.metrics.MetricRegistryInfo
- hashCode() - Method in class org.apache.hadoop.hbase.mob.CachedMobFile
- hashCode() - Method in class org.apache.hadoop.hbase.mob.MobFileName
- hashCode() - Method in class org.apache.hadoop.hbase.net.Address
- hashCode() - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
- hashCode() - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
- hashCode() - Method in class org.apache.hadoop.hbase.PerformanceEvaluation.RunResult
- hashCode() - Method in class org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot
- hashCode() - Method in class org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot.SpaceQuotaStatus
- hashCode() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
- hashCode() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreSize
- hashCode() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionSourceImpl
- hashCode() - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableSourceImpl
- hashCode() - Method in class org.apache.hadoop.hbase.regionserver.MetricsUserSourceImpl
- hashCode() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
- hashCode() - Method in class org.apache.hadoop.hbase.replication.ReplicationQueueId
- hashCode() - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
- hashCode() - Method in class org.apache.hadoop.hbase.security.User
- hashCode() - Method in class org.apache.hadoop.hbase.ServerName
- hashCode() - Method in class org.apache.hadoop.hbase.Size
- hashCode() - Method in class org.apache.hadoop.hbase.SizeCachedByteBufferKeyValue
- hashCode() - Method in class org.apache.hadoop.hbase.SizeCachedNoTagsByteBufferKeyValue
- hashCode() - Method in class org.apache.hadoop.hbase.SplitLogTask
-
Deprecated.
- hashCode() - Method in class org.apache.hadoop.hbase.TableName
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.CallQueue.Call
- hashCode() - Method in exception org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler.IOErrorWithCause
- hashCode() - Method in class org.apache.hadoop.hbase.tool.coprocessor.CoprocessorMethod
- hashCode() - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
- hashCode() - Method in class org.apache.hadoop.hbase.util.Bytes
- hashCode() - Method in class org.apache.hadoop.hbase.util.HashedBytes
- hashCode() - Method in class org.apache.hadoop.hbase.util.HbckRegionInfo.MetaEntry
- hashCode() - Method in class org.apache.hadoop.hbase.util.ImmutableByteArray
- hashCode() - Method in class org.apache.hadoop.hbase.util.NonceKey
- hashCode() - Method in class org.apache.hadoop.hbase.util.ObjectIntPair
- hashCode() - Method in class org.apache.hadoop.hbase.util.Pair
- hashCode() - Method in class org.apache.hadoop.hbase.util.PairOfSameType
- hashCode() - Method in class org.apache.hadoop.hbase.util.Triple
- hashCode() - Method in class org.apache.hadoop.hbase.wal.WALKeyImpl
- hashCode() - Method in class org.apache.hadoop.hbase.wal.WALSplitUtil.MutationReplay
- hashCode() - Method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp.CreateAndFailSilent
- hashCode() - Method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp.DeleteNodeFailSilent
- hashCode() - Method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp.SetData
- hashCode(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Calculate a hash code from a given byte array.
- hashCode(byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Calculate a hash code from a given byte array.
- hashCode(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Calculate the hash code for a given range of bytes.
- hashCode(ByteBuffer, int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
ByteBuffer to hash offset to start from length to hash
- hashCount - Variable in class org.apache.hadoop.hbase.util.BloomFilterChunk
-
Number of hash functions
- org.apache.hadoop.hbase.util.HashedBytes - Class in org.apache.hadoop.hbase.util
-
This class encapsulates a byte array and overrides hashCode and equals so that it's identity is based on the data rather than the array instance.
- HashedBytes(byte[]) - Constructor for class org.apache.hadoop.hbase.util.HashedBytes
- HASHES_MATCHED - Enum constant in enum class org.apache.hadoop.hbase.mapreduce.SyncTable.SyncMapper.Counter
- HASHES_NOT_MATCHED - Enum constant in enum class org.apache.hadoop.hbase.mapreduce.SyncTable.SyncMapper.Counter
- hasHigherPriority(ByteBuffer, ByteBuffer) - Method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Returns which operator has higher precedence
- org.apache.hadoop.hbase.util.HashKey<T> - Class in org.apache.hadoop.hbase.util
-
Used to calculate the hash
Hash
algorithms for Bloomfilters. - HashKey(T) - Constructor for class org.apache.hadoop.hbase.util.HashKey
- HashMapper() - Constructor for class org.apache.hadoop.hbase.mapreduce.HashTable.HashMapper
- org.apache.hadoop.hbase.mapreduce.HashTable - Class in org.apache.hadoop.hbase.mapreduce
- HashTable(Configuration) - Constructor for class org.apache.hadoop.hbase.mapreduce.HashTable
- org.apache.hadoop.hbase.mapreduce.HashTable.HashMapper - Class in org.apache.hadoop.hbase.mapreduce
- org.apache.hadoop.hbase.mapreduce.HashTable.TableHash - Class in org.apache.hadoop.hbase.mapreduce
- org.apache.hadoop.hbase.mapreduce.HashTable.TableHash.Reader - Class in org.apache.hadoop.hbase.mapreduce
- hashType - Variable in class org.apache.hadoop.hbase.io.hfile.CompoundBloomFilterBase
-
Hash function type to use, as defined in
Hash
- hashType - Variable in class org.apache.hadoop.hbase.util.BloomFilterChunk
-
Hash type
- hashWithAlg(String, byte[]...) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
-
Return the hash of the concatenation of the supplied arguments, using the hash algorithm provided.
- hasId() - Method in class org.apache.hadoop.hbase.zookeeper.ZKClusterId
- hasImmutableSegments() - Method in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
- hasLabels() - Method in class org.apache.hadoop.hbase.rest.RowSpec
- hasLeader() - Method in class org.apache.hadoop.hbase.zookeeper.ZKLeaderManager
-
Deprecated.
- hasMaster() - Method in class org.apache.hadoop.hbase.zookeeper.MasterAddressTracker
-
Check if there is a master available.
- org.apache.hadoop.hbase.coprocessor.HasMasterServices - Interface in org.apache.hadoop.hbase.coprocessor
-
Deprecated.Since 2.0.0 to be removed in 4.0.0. The hope was that by 3.0.0 we will not need this facility as CoreCoprocessors are integated into core but we failed, so delay the removal to 4.0.0.
- hasMergeRegions(Cell[]) - Static method in class org.apache.hadoop.hbase.CatalogFamilyFormat
-
Returns True if any merge regions present in
cells
; i.e. - hasMethod(Method) - Method in class org.apache.hadoop.hbase.tool.coprocessor.CoprocessorMethods
- hasMethod(String, Class<?>...) - Method in class org.apache.hadoop.hbase.tool.coprocessor.CoprocessorMethods
- hasMethod(String, String...) - Method in class org.apache.hadoop.hbase.tool.coprocessor.CoprocessorMethods
- hasMinimumVersion(HBaseProtos.VersionInfo, int, int) - Static method in class org.apache.hadoop.hbase.client.VersionInfoUtil
- hasMobColumns(TableDescriptor) - Static method in class org.apache.hadoop.hbase.mob.MobUtils
-
Checks whether this table has mob-enabled columns.
- hasMobReferenceTag(List<Tag>) - Static method in class org.apache.hadoop.hbase.mob.MobUtils
-
Whether the tag list has a mob reference tag.
- hasMoreValues() - Method in enum class org.apache.hadoop.hbase.regionserver.ScannerContext.NextState
- hasMoreValues(ScannerContext.NextState) - Static method in enum class org.apache.hadoop.hbase.regionserver.ScannerContext.NextState
- hasMVCCInfo() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
- hasMVCCInfo() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
- hasNext() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreCompactorSegmentsIterator
- hasNext() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreMergerSegmentsIterator
- hasNext() - Method in class org.apache.hadoop.hbase.rest.RowResultGenerator
- hasNext() - Method in class org.apache.hadoop.hbase.rest.ScannerResultGenerator
- hasNext() - Method in class org.apache.hadoop.hbase.types.StructIterator
- hasNext() - Method in class org.apache.hadoop.hbase.util.AvlUtil.AvlTreeIterator
- hasNext() - Method in class org.apache.hadoop.hbase.util.ConcatenatedLists.Iterator
- hasNonce() - Method in class org.apache.hadoop.hbase.client.Action
- hasNullColumn - Variable in class org.apache.hadoop.hbase.regionserver.querymatcher.UserScanQueryMatcher
- hasNullColumnInQuery() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.CompactionScanQueryMatcher
- hasNullColumnInQuery() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher
-
Returns whether there is an null column in the query
- hasNullColumnInQuery() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.UserScanQueryMatcher
- hasRecoveredEdits(Configuration, RegionInfo) - Static method in class org.apache.hadoop.hbase.wal.WALSplitUtil
-
Check whether there is recovered.edits in the region dir
- hasRecycler() - Method in class org.apache.hadoop.hbase.nio.RefCnt
-
Returns true if this refCnt has a recycler.
- hasReferences() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Returns True if this region has references.
- hasReferences() - Method in class org.apache.hadoop.hbase.regionserver.HStore
- hasReferences() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Returns
true
if the store has any underlying reference files to older HFiles - hasReferences() - Method in interface org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileTracker
-
Returns true if the specified family has reference files
- hasReferences(String) - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
Returns true if the specified family has reference files
- hasReferences(Collection<HStoreFile>) - Static method in class org.apache.hadoop.hbase.regionserver.StoreUtils
-
Determines whether any files in the collection are references.
- hasRegionInfo() - Method in interface org.apache.hadoop.hbase.ipc.HBaseRpcController
-
Returns True if this Controller is carrying the RPC target Region's RegionInfo.
- hasRegionInfo() - Method in class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
- hasRegionMemStoreReplication() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
Returns true if the read-replicas memstore replication is enabled.
- org.apache.hadoop.hbase.coprocessor.HasRegionServerServices - Interface in org.apache.hadoop.hbase.coprocessor
-
Deprecated.Since 2.0.0 to be removed in 4.0.0. The hope was that by 3.0.0 we will not need this facility as CoreCoprocessors are integated into core but we failed, so delay the removal to 4.0.0.
- hasRegionsToAdd() - Method in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper.RestoreMetaChanges
-
Returns true if there're new regions
- hasRegionsToRemove() - Method in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper.RestoreMetaChanges
-
Returns true if there're regions to remove
- hasRegionsToRestore() - Method in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper.RestoreMetaChanges
-
Returns true if there're regions to restore
- hasRemaining() - Method in class org.apache.hadoop.hbase.nio.ByteBuff
-
Returns true if there are elements between the current position and the limit.
- hasRemaining() - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
Returns true if there are elements between the current position and the limt
- hasRemaining() - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
- hasTableLimiters() - Method in class org.apache.hadoop.hbase.quotas.UserQuotaState
- hasTagCompression - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractProtobufWALReader
- hasTagCompression() - Method in class org.apache.hadoop.hbase.regionserver.wal.CompressionContext
- hasTimestamp() - Method in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
- hasTimestamp() - Method in class org.apache.hadoop.hbase.rest.RowSpec
- hasTooManyStoreFiles() - Method in class org.apache.hadoop.hbase.regionserver.HStore
- hasTooManyStoreFiles() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Returns Whether this store has too many store files.
- hasUnDeletedQueues() - Method in class org.apache.hadoop.hbase.util.hbck.ReplicationChecker
- hasUserPermissions(String, List<Permission>) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Check if the user has specific permissions
- hasUserPermissions(String, List<Permission>) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Check if the user has specific permissions
- hasUserPermissions(List<Permission>) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Check if call user has specific permissions
- hasUserPermissions(List<Permission>) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Check if call user has specific permissions
- hasUserPermissions(RpcController, AccessControlProtos.HasUserPermissionsRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- hasValidMobRefCellValue(Cell) - Static method in class org.apache.hadoop.hbase.mob.MobUtils
-
Indicates whether the current mob ref cell has a valid value.
- hasValueCompression - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractProtobufWALReader
- hasValueCompression() - Method in class org.apache.hadoop.hbase.regionserver.wal.CompressionContext
- org.apache.hadoop.hbase.backup.HBackupFileSystem - Class in org.apache.hadoop.hbase.backup
-
View to an on-disk Backup Image FileSytem Provides the set of methods necessary to interact with the on-disk Backup Image data.
- HBASE_BACKUP_COPY_IMPL_CLASS - Static variable in class org.apache.hadoop.hbase.backup.BackupRestoreFactory
- HBASE_BACKUP_MERGE_IMPL_CLASS - Static variable in class org.apache.hadoop.hbase.backup.BackupRestoreFactory
- HBASE_BALANCER_MAX_BALANCING - Static variable in class org.apache.hadoop.hbase.HConstants
-
Config for the max balancing time
- HBASE_BALANCER_PERIOD - Static variable in class org.apache.hadoop.hbase.HConstants
-
Config for the balancer period
- HBASE_CANARY_READ_ALL_CF - Static variable in class org.apache.hadoop.hbase.HConstants
- HBASE_CANARY_READ_RAW_SCAN_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
- HBASE_CANARY_WRITE_DATA_TTL_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
Canary config keys
- HBASE_CANARY_WRITE_PERSERVER_REGIONS_LOWERLIMIT_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
- HBASE_CANARY_WRITE_PERSERVER_REGIONS_UPPERLIMIT_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
- HBASE_CANARY_WRITE_TABLE_CHECK_PERIOD_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
- HBASE_CANARY_WRITE_VALUE_SIZE_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
- HBASE_CELLS_SCANNED_PER_HEARTBEAT_CHECK - Static variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
The number of cells scanned in between timeout checks.
- HBASE_CHECKSUM_VERIFICATION - Static variable in class org.apache.hadoop.hbase.HConstants
-
If this parameter is set to true, then hbase will read data and then verify checksums.
- HBASE_CLIENT_ASYNC_CONNECTION_IMPL - Static variable in class org.apache.hadoop.hbase.client.ConnectionFactory
- HBASE_CLIENT_AUTOMATIC_KEYTAB_RENEWAL_DEFAULT - Static variable in class org.apache.hadoop.hbase.AuthUtil
-
Deprecated.
- HBASE_CLIENT_AUTOMATIC_KEYTAB_RENEWAL_KEY - Static variable in class org.apache.hadoop.hbase.AuthUtil
-
Deprecated.Configuration to automatically try to renew keytab-based logins
- HBASE_CLIENT_CONNECTION_IMPL - Static variable in class org.apache.hadoop.hbase.client.ConnectionUtils
-
Key for configuration in Configuration whose value is the class we implement making a new Connection instance.
- HBASE_CLIENT_ENABLE_FAST_FAIL_MODE_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
-
Deprecated.since 2.3.0, and in 3.0.0 the actually implementation will be removed so config this value will have no effect. The constants itself will be removed in 4.0.0.
- HBASE_CLIENT_FAILURE_MAP_CLEANUP_INTERVAL_MS - Static variable in class org.apache.hadoop.hbase.HConstants
-
Deprecated.since 2.3.0, and in 3.0.0 the actually implementation will be removed so config this value will have no effect. The constants itself will be removed in 4.0.0.
- HBASE_CLIENT_FAILURE_MAP_CLEANUP_INTERVAL_MS_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
-
Deprecated.since 2.3.0, and in 3.0.0 the actually implementation will be removed so config this value will have no effect. The constants itself will be removed in 4.0.0.
- HBASE_CLIENT_FAST_FAIL_CLEANUP_DURATION_MS_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
-
Deprecated.since 2.3.0, and in 3.0.0 the actually implementation will be removed so config this value will have no effect. The constants itself will be removed in 4.0.0.
- HBASE_CLIENT_FAST_FAIL_CLEANUP_MS_DURATION_MS - Static variable in class org.apache.hadoop.hbase.HConstants
-
Deprecated.since 2.3.0, and in 3.0.0 the actually implementation will be removed so config this value will have no effect. The constants itself will be removed in 4.0.0.
- HBASE_CLIENT_FAST_FAIL_INTERCEPTOR_IMPL - Static variable in class org.apache.hadoop.hbase.HConstants
-
Deprecated.since 2.3.0, and in 3.0.0 the actually implementation will be removed so config this value will have no effect. The constants itself will be removed in 4.0.0.
- HBASE_CLIENT_FAST_FAIL_MODE_ENABLED - Static variable in class org.apache.hadoop.hbase.HConstants
-
Deprecated.since 2.3.0, and in 3.0.0 the actually implementation will be removed so config this value will have no effect. The constants itself will be removed in 4.0.0.
- HBASE_CLIENT_FAST_FAIL_THREASHOLD_MS - Static variable in class org.apache.hadoop.hbase.HConstants
-
Deprecated.since 2.3.0, and in 3.0.0 the actually implementation will be removed so config this value will have no effect. The constants itself will be removed in 4.0.0.
- HBASE_CLIENT_FAST_FAIL_THREASHOLD_MS_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
-
Deprecated.since 2.3.0, and in 3.0.0 the actually implementation will be removed so config this value will have no effect. The constants itself will be removed in 4.0.0.
- HBASE_CLIENT_INSTANCE_ID - Static variable in class org.apache.hadoop.hbase.HConstants
-
Parameter name for unique identifier for this
Configuration
instance. - HBASE_CLIENT_IPC_POOL_SIZE - Static variable in class org.apache.hadoop.hbase.HConstants
-
Parameter name for HBase client IPC pool size
- HBASE_CLIENT_IPC_POOL_TYPE - Static variable in class org.apache.hadoop.hbase.HConstants
-
Parameter name for HBase client IPC pool type
- HBASE_CLIENT_KERBEROS_PRINCIPAL - Static variable in class org.apache.hadoop.hbase.AuthUtil
-
Deprecated.Client principal
- HBASE_CLIENT_KEYTAB_FILE - Static variable in class org.apache.hadoop.hbase.AuthUtil
-
Deprecated.Client keytab file
- HBASE_CLIENT_MAX_PERREGION_TASKS - Static variable in class org.apache.hadoop.hbase.HConstants
-
The maximum number of concurrent connections the client will maintain to a single Region.
- HBASE_CLIENT_MAX_PERSERVER_TASKS - Static variable in class org.apache.hadoop.hbase.HConstants
-
The maximum number of concurrent connections the client will maintain to a single RegionServer.
- HBASE_CLIENT_MAX_TOTAL_TASKS - Static variable in class org.apache.hadoop.hbase.HConstants
-
The maximum number of concurrent connections the client will maintain.
- HBASE_CLIENT_META_OPERATION_TIMEOUT - Static variable in class org.apache.hadoop.hbase.HConstants
-
Parameter name for HBase client meta operation timeout.
- HBASE_CLIENT_META_READ_RPC_TIMEOUT_KEY - Static variable in class org.apache.hadoop.hbase.client.ConnectionConfiguration
- HBASE_CLIENT_META_REPLICA_SCAN_TIMEOUT - Static variable in class org.apache.hadoop.hbase.HConstants
-
Parameter name for HBase client meta replica scan call timeout.
- HBASE_CLIENT_META_REPLICA_SCAN_TIMEOUT_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
-
Default HBase client meta replica scan call timeout, 1 second
- HBASE_CLIENT_META_SCANNER_TIMEOUT - Static variable in class org.apache.hadoop.hbase.client.ConnectionConfiguration
- HBASE_CLIENT_NETTY_TLS_ENABLED - Static variable in class org.apache.hadoop.hbase.io.crypto.tls.X509Util
- HBASE_CLIENT_NETTY_TLS_HANDSHAKETIMEOUT - Static variable in class org.apache.hadoop.hbase.io.crypto.tls.X509Util
- HBASE_CLIENT_NETTY_TLS_VERIFY_SERVER_HOSTNAME - Static variable in class org.apache.hadoop.hbase.io.crypto.tls.X509Util
- HBASE_CLIENT_OPERATION_TIMEOUT - Static variable in class org.apache.hadoop.hbase.HConstants
-
Parameter name for HBase client operation timeout.
- HBASE_CLIENT_PAUSE - Static variable in class org.apache.hadoop.hbase.HConstants
-
Parameter name for client pause value, used mostly as value to wait before running a retry of a failed get, region lookup, etc.
- HBASE_CLIENT_PAUSE_FOR_CQTBE - Static variable in class org.apache.hadoop.hbase.HConstants
-
Deprecated.Since 2.5.0, will be removed in 4.0.0. Please use hbase.client.pause.server.overloaded instead.
- HBASE_CLIENT_PERSERVER_REQUESTS_THRESHOLD - Static variable in class org.apache.hadoop.hbase.HConstants
-
The maximum number of concurrent pending RPC requests for one server in process level.
- HBASE_CLIENT_RETRIES_NUMBER - Static variable in class org.apache.hadoop.hbase.HConstants
-
Parameter name for maximum retries, used as maximum for all retryable operations such as fetching of the root region from root region server, getting a cell's value, starting a row update, etc.
- HBASE_CLIENT_SCANNER_ASYNC_PREFETCH - Static variable in class org.apache.hadoop.hbase.client.Scan
-
Parameter name for client scanner sync/async prefetch toggle.
- HBASE_CLIENT_SCANNER_CACHING - Static variable in class org.apache.hadoop.hbase.HConstants
-
Parameter name to set the default scanner caching for all clients.
- HBASE_CLIENT_SCANNER_MAX_RESULT_SIZE_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
Parameter name for maximum number of bytes returned when calling a scanner's next method.
- HBASE_CLIENT_SCANNER_ONHEAP_BLOCK_CACHE_FIXED_SIZE_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
- HBASE_CLIENT_SCANNER_TIMEOUT_PERIOD - Static variable in class org.apache.hadoop.hbase.HConstants
-
The client scanner timeout period in milliseconds.
- HBASE_CLIENT_SERVERSIDE_RETRIES_MULTIPLIER - Static variable in class org.apache.hadoop.hbase.HConstants
- HBASE_CLUSTER_MINIMUM_MEMORY_THRESHOLD - Static variable in class org.apache.hadoop.hbase.HConstants
- HBASE_DIR - Static variable in class org.apache.hadoop.hbase.HConstants
-
Parameter name for HBase instance root directory
- HBASE_DIR_PERMS - Static variable in class org.apache.hadoop.hbase.master.MasterFileSystem
-
Parameter name for HBase instance root directory permission
- HBASE_ENABLE_SEPARATE_CHILD_REGIONS - Static variable in class org.apache.hadoop.hbase.HConstants
-
Config key for enable/disable automatically separate child regions to different region servers in the procedure of split regions.
- HBASE_FLUSH_POLICY_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.FlushPolicyFactory
- HBASE_FLUSH_THROUGHPUT_CONTROLLER_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.throttle.FlushThroughputControllerFactory
- HBASE_HSTORE_COMPACTION_MAX_THROUGHPUT_HIGHER_BOUND - Static variable in class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareCompactionThroughputController
- HBASE_HSTORE_COMPACTION_MAX_THROUGHPUT_LOWER_BOUND - Static variable in class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareCompactionThroughputController
- HBASE_HSTORE_COMPACTION_MAX_THROUGHPUT_OFFPEAK - Static variable in class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareCompactionThroughputController
- HBASE_HSTORE_COMPACTION_THROUGHPUT_TUNE_PERIOD - Static variable in class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareCompactionThroughputController
- HBASE_HSTORE_FLUSH_MAX_THROUGHPUT_LOWER_BOUND - Static variable in class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareFlushThroughputController
- HBASE_HSTORE_FLUSH_MAX_THROUGHPUT_UPPER_BOUND - Static variable in class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareFlushThroughputController
- HBASE_HSTORE_FLUSH_THROUGHPUT_CONTROL_CHECK_INTERVAL - Static variable in class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareFlushThroughputController
- HBASE_HSTORE_FLUSH_THROUGHPUT_TUNE_PERIOD - Static variable in class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareFlushThroughputController
- HBASE_HTTP_STATIC_USER - Static variable in interface org.apache.hadoop.hbase.http.ServerConfigurationKeys
- HBASE_INCR_RESTORE_IMPL_CLASS - Static variable in class org.apache.hadoop.hbase.backup.BackupRestoreFactory
- HBASE_JETTY_LOGS_SERVE_ALIASES - Static variable in interface org.apache.hadoop.hbase.http.ServerConfigurationKeys
-
Enable/Disable aliases serving from jetty
- HBASE_MASTER_BALANCER_MAX_RIT_PERCENT - Static variable in class org.apache.hadoop.hbase.HConstants
-
Config for the max percent of regions in transition
- HBASE_MASTER_CLEANER_INTERVAL - Static variable in class org.apache.hadoop.hbase.master.HMaster
- HBASE_MASTER_CLUSTER_SCHEMA_OPERATION_TIMEOUT_KEY - Static variable in interface org.apache.hadoop.hbase.master.ClusterSchema
-
Timeout for cluster operations in milliseconds.
- HBASE_MASTER_LOADBALANCE_BYTABLE - Static variable in class org.apache.hadoop.hbase.HConstants
-
Config for balancing the cluster by table
- HBASE_MASTER_LOADBALANCER_CLASS - Static variable in class org.apache.hadoop.hbase.HConstants
-
Config for pluggable load balancers
- HBASE_MASTER_LOGCLEANER_PLUGINS - Static variable in class org.apache.hadoop.hbase.HConstants
- HBASE_MASTER_NORMALIZER_CLASS - Static variable in class org.apache.hadoop.hbase.HConstants
-
Config for pluggable region normalizer
- HBASE_MASTER_WAIT_ON_SERVICE_IN_SECONDS - Static variable in class org.apache.hadoop.hbase.master.HMaster
- HBASE_MAX_CELL_SIZE_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.HRegion
- HBASE_META_BLOCK_SIZE - Static variable in class org.apache.hadoop.hbase.HConstants
-
Parameter name for number of versions, kept by meta table.
- HBASE_META_SCANNER_CACHING - Static variable in class org.apache.hadoop.hbase.HConstants
-
Parameter name for number of rows that will be fetched when calling next on a scanner if it is not served from memory.
- HBASE_META_VERSIONS - Static variable in class org.apache.hadoop.hbase.HConstants
-
Parameter name for number of versions, kept by meta table.
- HBASE_METRICS_SYSTEM_NAME - Static variable in interface org.apache.hadoop.hbase.metrics.BaseSource
- HBASE_NETTY_ALLOCATOR_KEY - Static variable in class org.apache.hadoop.hbase.ipc.NettyRpcServer
-
Name of property to change the byte buf allocator for the netty channels.
- HBASE_NETTY_EVENTLOOP_RPCCLIENT_THREADCOUNT_KEY - Static variable in class org.apache.hadoop.hbase.ipc.NettyRpcClientConfigHelper
-
Name of property to change netty rpc client eventloop thread count.
- HBASE_NON_TABLE_DIRS - Static variable in class org.apache.hadoop.hbase.HConstants
-
Directories that are not HBase table directories
- HBASE_NON_USER_TABLE_DIRS - Static variable in class org.apache.hadoop.hbase.HConstants
-
Deprecated.Since hbase-2.3.0; no replacement as not used any more (internally at least)
- HBASE_OLDWAL_DIR_SIZE_UPDATER_PERIOD - Static variable in class org.apache.hadoop.hbase.HConstants
-
Config for the oldWALs directory size updater period
- HBASE_REGION_SERVER_ENABLE_COMPACTION - Static variable in class org.apache.hadoop.hbase.regionserver.CompactSplit
- HBASE_REGION_SPLIT_POLICY_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
- HBASE_REGIONSERVER_MINIBATCH_SIZE - Static variable in class org.apache.hadoop.hbase.regionserver.HRegion
- HBASE_REPLICATION_PEER_BASE_CONFIG - Static variable in class org.apache.hadoop.hbase.client.replication.ReplicationPeerConfigUtil
- HBASE_RPC_READ_TIMEOUT_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
timeout for each read RPC
- HBASE_RPC_SHORTOPERATION_RETRY_PAUSE_TIME - Static variable in class org.apache.hadoop.hbase.HConstants
-
Retry pause time for short operation RPC
- HBASE_RPC_SHORTOPERATION_TIMEOUT_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
timeout for short operation RPC
- HBASE_RPC_TIMEOUT_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
timeout for each RPC
- HBASE_RPC_WRITE_TIMEOUT_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
timeout for each write RPC
- HBASE_RS_HEAP_MEMORY_TUNER_CLASS - Static variable in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager
- HBASE_RS_HEAP_MEMORY_TUNER_DEFAULT_PERIOD - Static variable in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager
- HBASE_RS_HEAP_MEMORY_TUNER_PERIOD - Static variable in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager
- HBASE_RS_NONCES_ENABLED - Static variable in class org.apache.hadoop.hbase.HConstants
-
Whether nonces are enabled; default is true.
- HBASE_RSGROUP_LOADBALANCER_CLASS - Static variable in interface org.apache.hadoop.hbase.master.LoadBalancer
-
Deprecated.since 3.0.0, will be removed in 4.0.0. In the new implementation, as the base load balancer will always be the rs group based one, you should just use
HConstants.HBASE_MASTER_LOADBALANCER_CLASS
to config the per group load balancer. - HBASE_SECURITY_AUTHORIZATION_CONF_KEY - Static variable in class org.apache.hadoop.hbase.security.User
- HBASE_SECURITY_CONF_KEY - Static variable in class org.apache.hadoop.hbase.security.User
- HBASE_SERVER_CLUSTER_CONNECTION_IMPL - Static variable in class org.apache.hadoop.hbase.client.ClusterConnectionFactory
- HBASE_SERVER_NETTY_TLS_CLIENT_AUTH_MODE - Static variable in class org.apache.hadoop.hbase.io.crypto.tls.X509Util
- HBASE_SERVER_NETTY_TLS_ENABLED - Static variable in class org.apache.hadoop.hbase.io.crypto.tls.X509Util
- HBASE_SERVER_NETTY_TLS_SUPPORTPLAINTEXT - Static variable in class org.apache.hadoop.hbase.io.crypto.tls.X509Util
- HBASE_SERVER_NETTY_TLS_VERIFY_CLIENT_HOSTNAME - Static variable in class org.apache.hadoop.hbase.io.crypto.tls.X509Util
- HBASE_SERVER_NETTY_TLS_WRAP_SIZE - Static variable in class org.apache.hadoop.hbase.io.crypto.tls.X509Util
-
Set the SSL wrapSize for netty.
- HBASE_SERVER_PAUSE - Static variable in class org.apache.hadoop.hbase.HConstants
-
Parameter name for server pause value, used mostly as value to wait before running a retry of a failed operation.
- HBASE_SERVER_SCANNER_MAX_RESULT_SIZE_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
Parameter name for maximum number of bytes returned when calling a scanner's next method.
- HBASE_SERVER_USEIP_ENABLED_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
-
Default value of
HConstants.HBASE_SERVER_USEIP_ENABLED_KEY
- HBASE_SERVER_USEIP_ENABLED_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
In some scenarios, such as the elastic scaling scenario on the cloud, the HBase client may not be able to resolve the hostname of the newly added node.
- HBASE_SPLIT_WAL_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, replaced by procedure-based distributed WAL splitter; see SplitWALManager.
- HBASE_SPLIT_WAL_MAX_SPLITTER - Static variable in class org.apache.hadoop.hbase.HConstants
- HBASE_SPLITLOG_MANAGER_TIMEOUT - Static variable in class org.apache.hadoop.hbase.HConstants
-
Configuration key for SplitLog manager timeout
- HBASE_SSL_ENABLED_DEFAULT - Static variable in interface org.apache.hadoop.hbase.http.ServerConfigurationKeys
- HBASE_SSL_ENABLED_KEY - Static variable in interface org.apache.hadoop.hbase.http.ServerConfigurationKeys
-
Enable/Disable ssl for http server
- HBASE_TEMP_DIRECTORY - Static variable in class org.apache.hadoop.hbase.HConstants
-
Temporary directory used for table creation and deletion
- HBASE_THRIFT_CLIENT_BUIDLER_CLASS - Static variable in class org.apache.hadoop.hbase.thrift.Constants
- HBASE_THRIFT_CLIENT_SCANNER_CACHING - Static variable in class org.apache.hadoop.hbase.thrift.Constants
- HBASE_THRIFT_CLIENT_SCANNER_CACHING_DEFAULT - Static variable in class org.apache.hadoop.hbase.thrift.Constants
- HBASE_THRIFT_SERVER_NAME - Static variable in class org.apache.hadoop.hbase.thrift.Constants
- HBASE_THRIFT_SERVER_PORT - Static variable in class org.apache.hadoop.hbase.thrift.Constants
- HBASE_THROUGHPUT_CONTROLLER_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.throttle.CompactionThroughputControllerFactory
- HBASE_VERSION - Enum constant in enum class org.apache.hadoop.hbase.ClusterMetrics.Option
-
metrics about hbase version
- HBASE_WAL_DIR - Static variable in class org.apache.hadoop.hbase.util.CommonFSUtils
-
Parameter name for HBase WAL directory
- HBASE_WAL_DIR_PERMS - Static variable in class org.apache.hadoop.hbase.master.MasterFileSystem
-
Parameter name for HBase WAL directory permission
- hbaseCluster - Variable in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.
- org.apache.hadoop.hbase.HBaseCluster - Class in org.apache.hadoop.hbase
-
Deprecated.since 3.0.0, will be removed in 4.0.0. Use
TestingHBaseCluster
instead. - HBaseCluster(Configuration) - Constructor for class org.apache.hadoop.hbase.HBaseCluster
-
Deprecated.Construct an HBaseCluster
- org.apache.hadoop.hbase.HBaseCommonTestingUtility - Class in org.apache.hadoop.hbase
-
Deprecated.since 3.0.0, will be removed in 4.0.0. Use
TestingHBaseCluster
instead. - HBaseCommonTestingUtility() - Constructor for class org.apache.hadoop.hbase.HBaseCommonTestingUtility
-
Deprecated.
- HBaseCommonTestingUtility(Configuration) - Constructor for class org.apache.hadoop.hbase.HBaseCommonTestingUtility
-
Deprecated.
- org.apache.hadoop.hbase.HBaseConfiguration - Class in org.apache.hadoop.hbase
-
Adds HBase configuration files to a Configuration
- HBaseConfiguration() - Constructor for class org.apache.hadoop.hbase.HBaseConfiguration
- org.apache.hadoop.hbase.util.HBaseConfTool - Class in org.apache.hadoop.hbase.util
-
Tool that prints out a configuration.
- HBaseConfTool() - Constructor for class org.apache.hadoop.hbase.util.HBaseConfTool
- org.apache.hadoop.hbase.exceptions.HBaseException - Exception in org.apache.hadoop.hbase.exceptions
-
Base checked exception in HBase.
- HBaseException() - Constructor for exception org.apache.hadoop.hbase.exceptions.HBaseException
- HBaseException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.HBaseException
- HBaseException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.exceptions.HBaseException
- HBaseException(Throwable) - Constructor for exception org.apache.hadoop.hbase.exceptions.HBaseException
- org.apache.hadoop.hbase.util.HBaseFsck - Class in org.apache.hadoop.hbase.util
-
Deprecated.For removal in hbase-4.0.0. Use HBCK2 instead.
- HBaseFsck(Configuration) - Constructor for class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.Constructor
- HBaseFsck(Configuration, ExecutorService) - Constructor for class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.Constructor Configuration object if the master is not running if unable to connect to ZooKeeper
- org.apache.hadoop.hbase.util.HBaseFsckRepair - Class in org.apache.hadoop.hbase.util
-
This class contains helper methods that repair parts of hbase's filesystem contents.
- HBaseFsckRepair() - Constructor for class org.apache.hadoop.hbase.util.HBaseFsckRepair
- org.apache.hadoop.hbase.thrift.HbaseHandlerMetricsProxy - Class in org.apache.hadoop.hbase.thrift
-
Converts a Hbase.Iface using InvocationHandler so that it reports process time of each call to ThriftMetrics.
- org.apache.hadoop.hbase.client.HBaseHbck - Class in org.apache.hadoop.hbase.client
-
Use
Connection.getHbck()
to obtain an instance ofHbck
instead of constructing an HBaseHbck directly. - org.apache.hadoop.hbase.HBaseInterfaceAudience - Class in org.apache.hadoop.hbase
-
This class defines constants for different classes of hbase limited private apis
- org.apache.hadoop.hbase.HBaseIOException - Exception in org.apache.hadoop.hbase
-
All hbase specific IOExceptions should be subclasses of HBaseIOException
- HBaseIOException() - Constructor for exception org.apache.hadoop.hbase.HBaseIOException
- HBaseIOException(String) - Constructor for exception org.apache.hadoop.hbase.HBaseIOException
- HBaseIOException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.HBaseIOException
- HBaseIOException(Throwable) - Constructor for exception org.apache.hadoop.hbase.HBaseIOException
- org.apache.hadoop.hbase.log.HBaseMarkers - Class in org.apache.hadoop.hbase.log
- org.apache.hadoop.hbase.security.HBasePolicyProvider - Class in org.apache.hadoop.hbase.security
-
Implementation of secure Hadoop policy provider for mapping protocol interfaces to hbase-policy.xml entries.
- HBasePolicyProvider() - Constructor for class org.apache.hadoop.hbase.security.HBasePolicyProvider
- HBaseReaderThread(int) - Constructor for class org.apache.hadoop.hbase.util.MultiThreadedReader.HBaseReaderThread
- HBaseReaderThreadWithACL(int) - Constructor for class org.apache.hadoop.hbase.util.MultiThreadedReaderWithACL.HBaseReaderThreadWithACL
- org.apache.hadoop.hbase.nio.HBaseReferenceCounted - Interface in org.apache.hadoop.hbase.nio
-
The HBaseReferenceCounted disabled several methods in Netty's
ReferenceCounted
, because those methods are unlikely to be used. - org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint - Class in org.apache.hadoop.hbase.replication
-
A
BaseReplicationEndpoint
for replication endpoints whose target cluster is an HBase cluster. - HBaseReplicationEndpoint() - Constructor for class org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint
- org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint.SinkPeer - Class in org.apache.hadoop.hbase.replication
-
Wraps a replication region server sink to provide the ability to identify it.
- org.apache.hadoop.hbase.ipc.HBaseRpcController - Interface in org.apache.hadoop.hbase.ipc
-
Optionally carries Cells across the proxy/service interface down into ipc.
- org.apache.hadoop.hbase.ipc.HBaseRpcController.CancellationCallback - Interface in org.apache.hadoop.hbase.ipc
- org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl - Class in org.apache.hadoop.hbase.ipc
-
Get instances via
RpcControllerFactory
on client-side. - HBaseRpcControllerImpl() - Constructor for class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
- HBaseRpcControllerImpl(ExtendedCellScanner) - Constructor for class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
-
Used server-side.
- org.apache.hadoop.hbase.ipc.HBaseRPCErrorHandler - Interface in org.apache.hadoop.hbase.ipc
-
An interface for calling out of RPC for error conditions.
- org.apache.hadoop.hbase.HBaseRpcServicesBase<S extends org.apache.hadoop.hbase.HBaseServerBase<?>> - Class in org.apache.hadoop.hbase
-
Base class for Master and RegionServer RpcServices.
- HBaseRpcServicesBase(S, String) - Constructor for class org.apache.hadoop.hbase.HBaseRpcServicesBase
- org.apache.hadoop.hbase.security.HBaseSaslRpcClient - Class in org.apache.hadoop.hbase.security
-
A utility class that encapsulates SASL logic for RPC client.
- HBaseSaslRpcClient(Configuration, SaslClientAuthenticationProvider, Token<? extends TokenIdentifier>, InetAddress, String, boolean) - Constructor for class org.apache.hadoop.hbase.security.HBaseSaslRpcClient
- HBaseSaslRpcClient(Configuration, SaslClientAuthenticationProvider, Token<? extends TokenIdentifier>, InetAddress, String, boolean, String, boolean) - Constructor for class org.apache.hadoop.hbase.security.HBaseSaslRpcClient
- org.apache.hadoop.hbase.security.HBaseSaslRpcServer - Class in org.apache.hadoop.hbase.security
-
A utility class that encapsulates SASL logic for RPC server.
- HBaseSaslRpcServer(SaslServerAuthenticationProvider, Map<String, String>, SecretManager<TokenIdentifier>) - Constructor for class org.apache.hadoop.hbase.security.HBaseSaslRpcServer
- org.apache.hadoop.hbase.HBaseServerBase<R extends org.apache.hadoop.hbase.HBaseRpcServicesBase<?>> - Class in org.apache.hadoop.hbase
-
Base class for hbase services, such as master or region server.
- HBaseServerBase(Configuration, String) - Constructor for class org.apache.hadoop.hbase.HBaseServerBase
- org.apache.hadoop.hbase.HBaseServerException - Exception in org.apache.hadoop.hbase
-
Base class for exceptions thrown by an HBase server.
- HBaseServerException() - Constructor for exception org.apache.hadoop.hbase.HBaseServerException
- HBaseServerException(boolean) - Constructor for exception org.apache.hadoop.hbase.HBaseServerException
- HBaseServerException(boolean, String) - Constructor for exception org.apache.hadoop.hbase.HBaseServerException
- HBaseServerException(String) - Constructor for exception org.apache.hadoop.hbase.HBaseServerException
- org.apache.hadoop.hbase.client.backoff.HBaseServerExceptionPauseManager - Class in org.apache.hadoop.hbase.client.backoff
- HBaseServerExceptionPauseManager(long, long, long) - Constructor for class org.apache.hadoop.hbase.client.backoff.HBaseServerExceptionPauseManager
- hbaseServiceHandler - Variable in class org.apache.hadoop.hbase.thrift.ThriftServer
- org.apache.hadoop.hbase.thrift.HBaseServiceHandler - Class in org.apache.hadoop.hbase.thrift
-
abstract class for HBase handler providing a Connection cache and get table/admin method
- HBaseServiceHandler(Configuration, UserProvider) - Constructor for class org.apache.hadoop.hbase.thrift.HBaseServiceHandler
- org.apache.hadoop.hbase.snapshot.HBaseSnapshotException - Exception in org.apache.hadoop.hbase.snapshot
-
General exception base class for when a snapshot fails.
- HBaseSnapshotException(String) - Constructor for exception org.apache.hadoop.hbase.snapshot.HBaseSnapshotException
-
Some exception happened for a snapshot and don't even know the snapshot that it was about.
- HBaseSnapshotException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.snapshot.HBaseSnapshotException
-
Exception when the description of the snapshot cannot be determined, due to some root other root cause.
- HBaseSnapshotException(String, Throwable, SnapshotDescription) - Constructor for exception org.apache.hadoop.hbase.snapshot.HBaseSnapshotException
-
Exception for the given snapshot due to another exception.
- HBaseSnapshotException(String, SnapshotDescription) - Constructor for exception org.apache.hadoop.hbase.snapshot.HBaseSnapshotException
-
Exception for the given snapshot that has no previous root cause.
- org.apache.hadoop.hbase.HBaseTestingUtility - Class in org.apache.hadoop.hbase
-
Deprecated.since 3.0.0, will be removed in 4.0.0. Use
TestingHBaseCluster
instead. - HBaseTestingUtility() - Constructor for class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Create an HBaseTestingUtility using a default configuration.
- HBaseTestingUtility(Configuration) - Constructor for class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Create an HBaseTestingUtility using a given configuration.
- org.apache.hadoop.hbase.HBaseTestingUtility.SeenRowTracker - Class in org.apache.hadoop.hbase
-
Deprecated.A tracker for tracking and validating table rows generated with
HBaseTestingUtility.loadTable(Table, byte[])
- org.apache.hadoop.hbase.io.crypto.tls.HBaseTrustManager - Class in org.apache.hadoop.hbase.io.crypto.tls
-
A custom TrustManager that supports hostname verification We attempt to perform verification using just the IP address first and if that fails will attempt to perform a reverse DNS lookup and verify using the hostname.
- HBaseUpdaterThread(int) - Constructor for class org.apache.hadoop.hbase.util.MultiThreadedUpdater.HBaseUpdaterThread
- HBaseUpdaterThreadWithACL(int) - Constructor for class org.apache.hadoop.hbase.util.MultiThreadedUpdaterWithACL.HBaseUpdaterThreadWithACL
- HBaseWriterThread(int) - Constructor for class org.apache.hadoop.hbase.util.MultiThreadedWriter.HBaseWriterThread
- HBaseWriterThreadWithACL(int) - Constructor for class org.apache.hadoop.hbase.util.MultiThreadedWriterWithACL.HBaseWriterThreadWithACL
- org.apache.hadoop.hbase.HBaseZKTestingUtility - Class in org.apache.hadoop.hbase
-
Deprecated.since 3.0.0, will be removed in 4.0.0. Use
TestingHBaseCluster
instead. - HBaseZKTestingUtility() - Constructor for class org.apache.hadoop.hbase.HBaseZKTestingUtility
-
Deprecated.
- HBaseZKTestingUtility(Configuration) - Constructor for class org.apache.hadoop.hbase.HBaseZKTestingUtility
-
Deprecated.
- org.apache.hadoop.hbase.client.Hbck - Interface in org.apache.hadoop.hbase.client
-
Hbck fixup tool APIs.
- HBCK - Static variable in class org.apache.hadoop.hbase.HBaseInterfaceAudience
-
Denotes classes used by hbck tool for fixing inconsistent state of HBase.
- HBCK_LOCK_FILE - Static variable in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.Here is where hbase-1.x used to default the lock for hbck1.
- HBCK_SIDELINEDIR_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
-
Used by HBCK to sideline backup data
- org.apache.hadoop.hbase.HbckEmptyRegionInfo - Class in org.apache.hadoop.hbase
-
POJO to present Empty Region Info from Catalog Janitor Inconsistencies Report via REST API.
- HbckEmptyRegionInfo(String) - Constructor for class org.apache.hadoop.hbase.HbckEmptyRegionInfo
- org.apache.hadoop.hbase.util.HbckErrorReporter - Interface in org.apache.hadoop.hbase.util
-
Deprecated.Since 2.3.0. To be removed in hbase4. Use HBCK2 instead. Remove when
HBaseFsck
is removed. - org.apache.hadoop.hbase.util.HbckErrorReporter.ERROR_CODE - Enum Class in org.apache.hadoop.hbase.util
-
Deprecated.
- org.apache.hadoop.hbase.HbckInconsistentRegions - Class in org.apache.hadoop.hbase
-
POJO to present HBCK Inconsistent Regions from HBCK Inconsistencies Report via REST API.
- HbckInconsistentRegions(String, HbckServerName, List<HbckServerName>) - Constructor for class org.apache.hadoop.hbase.HbckInconsistentRegions
- org.apache.hadoop.hbase.HbckOrphanRegionsOnFS - Class in org.apache.hadoop.hbase
-
POJO to present Orphan Region on FS from HBCK Inconsistencies Report via REST API.
- HbckOrphanRegionsOnFS(String, String) - Constructor for class org.apache.hadoop.hbase.HbckOrphanRegionsOnFS
- org.apache.hadoop.hbase.HbckOrphanRegionsOnRS - Class in org.apache.hadoop.hbase
-
POJO to present Orphan Region on RS from HBCK Inconsistencies Report via REST API.
- HbckOrphanRegionsOnRS(String, HbckServerName) - Constructor for class org.apache.hadoop.hbase.HbckOrphanRegionsOnRS
- org.apache.hadoop.hbase.HbckOverlapRegions - Class in org.apache.hadoop.hbase
-
POJO to present Region Overlap from Catalog Janitor Inconsistencies Report via REST API.
- HbckOverlapRegions(HbckRegionDetails, HbckRegionDetails) - Constructor for class org.apache.hadoop.hbase.HbckOverlapRegions
- org.apache.hadoop.hbase.HbckRegionDetails - Class in org.apache.hadoop.hbase
-
POJO class for HBCK RegionInfo in HBCK Inconsistencies report.
- HbckRegionDetails(String, String, String, String) - Constructor for class org.apache.hadoop.hbase.HbckRegionDetails
- org.apache.hadoop.hbase.HbckRegionHoles - Class in org.apache.hadoop.hbase
-
POJO to present Region Holes from Catalog Janitor Inconsistencies Report via REST API.
- HbckRegionHoles(HbckRegionDetails, HbckRegionDetails) - Constructor for class org.apache.hadoop.hbase.HbckRegionHoles
- org.apache.hadoop.hbase.util.HbckRegionInfo - Class in org.apache.hadoop.hbase.util
-
Maintain information about a particular region.
- HbckRegionInfo(HbckRegionInfo.MetaEntry) - Constructor for class org.apache.hadoop.hbase.util.HbckRegionInfo
- org.apache.hadoop.hbase.util.HbckRegionInfo.HdfsEntry - Class in org.apache.hadoop.hbase.util
-
Stores the regioninfo entries from HDFS
- org.apache.hadoop.hbase.util.HbckRegionInfo.MetaEntry - Class in org.apache.hadoop.hbase.util
-
Stores the regioninfo entries scanned from META
- org.apache.hadoop.hbase.HbckServerName - Class in org.apache.hadoop.hbase
-
POJO class for ServerName in HBCK Inconsistencies report.
- HbckServerName(String, int, long) - Constructor for class org.apache.hadoop.hbase.HbckServerName
- org.apache.hadoop.hbase.util.HbckTableInfo - Class in org.apache.hadoop.hbase.util
-
Maintain information about a particular table.
- org.apache.hadoop.hbase.HbckUnknownServers - Class in org.apache.hadoop.hbase
-
POJO to present Unknown Regions from Catalog Janitor Inconsistencies Report via REST API.
- HbckUnknownServers(HbckRegionDetails, HbckServerName) - Constructor for class org.apache.hadoop.hbase.HbckUnknownServers
- org.apache.hadoop.hbase.hbtop.HBTop - Class in org.apache.hadoop.hbase.hbtop
-
A real-time monitoring tool for HBase like Unix top command.
- HBTop() - Constructor for class org.apache.hadoop.hbase.hbtop.HBTop
- HBTop(Configuration) - Constructor for class org.apache.hadoop.hbase.hbtop.HBTop
- org.apache.hadoop.hbase.HConstants - Class in org.apache.hadoop.hbase
-
HConstants holds a bunch of HBase-related constants
- org.apache.hadoop.hbase.HConstants.OperationStatusCode - Enum Class in org.apache.hadoop.hbase
-
Status codes used for return values of bulk operations.
- org.apache.hadoop.hbase.HDFSBlocksDistribution - Class in org.apache.hadoop.hbase
-
Data structure to describe the distribution of HDFS blocks among hosts.
- HDFSBlocksDistribution() - Constructor for class org.apache.hadoop.hbase.HDFSBlocksDistribution
- org.apache.hadoop.hbase.HDFSBlocksDistribution.HostAndWeight - Class in org.apache.hadoop.hbase
-
Stores the hostname and weight for that hostname.
- org.apache.hadoop.hbase.HDFSBlocksDistribution.HostAndWeight.WeightComparator - Class in org.apache.hadoop.hbase
-
Comparator used to sort hosts based on weight
- org.apache.hadoop.hbase.HDFSBlocksDistribution.Visitor - Interface in org.apache.hadoop.hbase
-
Implementations 'visit' hostAndWeight.
- HdfsEntry(Path) - Constructor for class org.apache.hadoop.hbase.util.HbckRegionInfo.HdfsEntry
- head(byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Make a new byte array from a subset of bytes at the head of another.
- head(String) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Send a HEAD request
- head(Cluster, String, Header[]) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Send a HEAD request
- header - Variable in class org.apache.hadoop.hbase.ipc.ServerCall
- org.apache.hadoop.hbase.hbtop.screen.top.Header - Class in org.apache.hadoop.hbase.hbtop.screen.top
-
Represents headers for the metrics in the top screen.
- Header(Field, int) - Constructor for class org.apache.hadoop.hbase.hbtop.screen.top.Header
- headerSize() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
Returns the size of this block header.
- headerSize(boolean) - Static method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
Maps a minor version to the size of the header.
- headMap(byte[]) - Method in class org.apache.hadoop.hbase.io.hfile.HFileInfo
- headMap(K) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
- headMap(K, boolean) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
- headMap(T) - Method in class org.apache.hadoop.hbase.regionserver.CellFlatMap
- headMap(T, boolean) - Method in class org.apache.hadoop.hbase.regionserver.CellFlatMap
- headSet(ExtendedCell) - Method in class org.apache.hadoop.hbase.regionserver.CompositeImmutableSegment
- headSet(ExtendedCell) - Method in class org.apache.hadoop.hbase.regionserver.Segment
- headSet(T) - Method in class org.apache.hadoop.hbase.regionserver.CellSet
- headSet(T, boolean) - Method in class org.apache.hadoop.hbase.regionserver.CellSet
- HEALTH_CHORE_WAKE_FREQ - Static variable in class org.apache.hadoop.hbase.HConstants
- HEALTH_FAILURE_THRESHOLD - Static variable in class org.apache.hadoop.hbase.HConstants
-
The maximum number of health check failures a server can encounter consecutively.
- HEALTH_SCRIPT_LOC - Static variable in class org.apache.hadoop.hbase.HConstants
-
Health script related settings.
- HEALTH_SCRIPT_TIMEOUT - Static variable in class org.apache.hadoop.hbase.HConstants
- org.apache.hadoop.hbase.HealthCheckChore - Class in org.apache.hadoop.hbase
-
The Class HealthCheckChore for running health checker regularly.
- HealthCheckChore(int, Stoppable, Configuration) - Constructor for class org.apache.hadoop.hbase.HealthCheckChore
- heap - Variable in class org.apache.hadoop.hbase.regionserver.KeyValueHeap
- heap - Variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
- HEAP - Static variable in class org.apache.hadoop.hbase.io.ByteBuffAllocator
- HEAP_OCCUPANCY_ERROR_VALUE - Static variable in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager
- HEAP_OCCUPANCY_HIGH_WATERMARK_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
- HEAP_OCCUPANCY_LOW_WATERMARK_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
- org.apache.hadoop.hbase.ipc.HeapByteBufAllocator - Class in org.apache.hadoop.hbase.ipc
-
A pooled ByteBufAllocator that does not prefer direct buffers regardless of platform settings.
- HeapByteBufAllocator() - Constructor for class org.apache.hadoop.hbase.ipc.HeapByteBufAllocator
- org.apache.hadoop.hbase.regionserver.HeapMemoryManager - Class in org.apache.hadoop.hbase.regionserver
-
Manages tuning of Heap memory using
HeapMemoryTuner
. - org.apache.hadoop.hbase.regionserver.HeapMemoryManager.HeapMemoryTuneObserver - Interface in org.apache.hadoop.hbase.regionserver
-
Every class that wants to observe heap memory tune actions must implement this interface.
- org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerContext - Class in org.apache.hadoop.hbase.regionserver
-
POJO to pass all the relevant information required to do the heap memory tuning.
- org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerResult - Class in org.apache.hadoop.hbase.regionserver
-
POJO which holds the result of memory tuning done by HeapMemoryTuner implementation.
- org.apache.hadoop.hbase.regionserver.HeapMemoryTuner - Interface in org.apache.hadoop.hbase.regionserver
-
Makes the decision regarding proper sizing of the heap memory.
- heapSize() - Method in class org.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValue
- heapSize() - Method in class org.apache.hadoop.hbase.ByteBufferKeyValue
- heapSize() - Method in class org.apache.hadoop.hbase.client.Mutation
-
Returns Calculate what Mutation adds to class heap size.
- heapSize() - Method in class org.apache.hadoop.hbase.IndividualBytesFieldCell
-
Implement HeapSize interface
- heapSize() - Method in interface org.apache.hadoop.hbase.io.HeapSize
-
Return the approximate 'exclusive deep size' of implementing object.
- heapSize() - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheKey
-
Strings have two bytes per character due to default Java Unicode encoding (hence length times 2).
- heapSize() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
- heapSize() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
- heapSize() - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
-
HeapSize implementation.
- heapSize() - Method in class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache
- heapSize() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
- heapSize() - Method in class org.apache.hadoop.hbase.io.hfile.LruCachedBlock
- heapSize() - Method in class org.apache.hadoop.hbase.io.hfile.LruCachedBlockQueue
-
Total size of all elements in this queue.
- heapSize() - Method in class org.apache.hadoop.hbase.io.hfile.NoOpIndexBlockEncoder.NoOpEncodedSeeker
- heapSize() - Method in class org.apache.hadoop.hbase.io.hfile.TinyLfuBlockCache
- heapSize() - Method in class org.apache.hadoop.hbase.KeyValue
-
HeapSize implementation
- heapSize() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
- heapSize() - Method in class org.apache.hadoop.hbase.quotas.NoOpRegionSizeStore
- heapSize() - Method in class org.apache.hadoop.hbase.quotas.RegionSizeImpl
- heapSize() - Method in class org.apache.hadoop.hbase.quotas.RegionSizeStoreImpl
- heapSize() - Method in class org.apache.hadoop.hbase.regionserver.AbstractMemStore
- heapSize() - Method in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
- heapSize() - Method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore
- heapSize() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
- heapSize() - Method in class org.apache.hadoop.hbase.regionserver.HStore
- heapSize() - Method in class org.apache.hadoop.hbase.regionserver.StoreContext
- heapSize() - Method in class org.apache.hadoop.hbase.SizeCachedByteBufferKeyValue
- heapSize() - Method in class org.apache.hadoop.hbase.SizeCachedKeyValue
- heapSize() - Method in class org.apache.hadoop.hbase.SizeCachedNoTagsByteBufferKeyValue
- heapSize() - Method in class org.apache.hadoop.hbase.util.MapReduceExtendedCell
- heapSize() - Method in class org.apache.hadoop.hbase.wal.WALEdit
- org.apache.hadoop.hbase.io.HeapSize - Interface in org.apache.hadoop.hbase.io
-
Implementations can be asked for an estimate of their size in bytes.
- heapSizeChange(Cell, boolean) - Method in class org.apache.hadoop.hbase.regionserver.Segment
- HEART_BEAT_SEQNO - Static variable in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputHelper
- heartbeat(long, int, ServerName) - Method in class org.apache.hadoop.hbase.master.SplitLogManager.Task
-
Deprecated.
- HEARTBEAT_TIME_BUFFER - Static variable in class org.apache.hadoop.hbase.client.locking.EntityLock
- heartbeatNoDetails(long) - Method in class org.apache.hadoop.hbase.master.SplitLogManager.Task
-
Deprecated.
- HEDGED_READ - Enum constant in enum class org.apache.hadoop.hbase.CatalogReplicaMode
- HEDGED_READ_IN_CUR_THREAD - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- HEDGED_READ_IN_CUR_THREAD_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- HEDGED_READ_WINS - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- HEDGED_READ_WINS_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- HEDGED_READS - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- HEDGED_READS_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- HEDGED_REQS_FANOUT_DEFAULT - Static variable in class org.apache.hadoop.hbase.client.MasterRegistry
-
Default value for the fan out of hedged requests.
- HEDGED_REQS_FANOUT_KEY - Static variable in class org.apache.hadoop.hbase.client.RpcConnectionRegistry
-
Configuration key that controls the fan out of requests
- org.apache.hbase.archetypes.exemplars.client.HelloHBase - Class in org.apache.hbase.archetypes.exemplars.client
-
Successful running of this application requires access to an active instance of HBase.
- org.apache.hbase.archetypes.exemplars.shaded_client.HelloHBase - Class in org.apache.hbase.archetypes.exemplars.shaded_client
-
Successful running of this application requires access to an active instance of HBase.
- HELP - Enum constant in enum class org.apache.hadoop.hbase.backup.BackupRestoreConstants.BackupCommand
- org.apache.hadoop.hbase.hbtop.screen.help.HelpScreenPresenter - Class in org.apache.hadoop.hbase.hbtop.screen.help
-
The presentation logic for the help screen.
- HelpScreenPresenter(HelpScreenView, long, ScreenView) - Constructor for class org.apache.hadoop.hbase.hbtop.screen.help.HelpScreenPresenter
- org.apache.hadoop.hbase.hbtop.screen.help.HelpScreenView - Class in org.apache.hadoop.hbase.hbtop.screen.help
-
The help screen.
- HelpScreenView(Screen, Terminal, long, ScreenView) - Constructor for class org.apache.hadoop.hbase.hbtop.screen.help.HelpScreenView
- HexStringSplit() - Constructor for class org.apache.hadoop.hbase.util.RegionSplitter.HexStringSplit
- org.apache.hadoop.hbase.io.hfile.HFile - Class in org.apache.hadoop.hbase.io.hfile
-
File format for hbase.
- HFILE_ARCHIVE_DIRECTORY - Static variable in class org.apache.hadoop.hbase.HConstants
-
Directory under /hbase where archived hfiles are stored
- HFILE_BLOCK_CACHE_SIZE_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
- HFILE_BLOCK_CACHE_SIZE_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
Configuration key for the size of the block cache
- HFILE_NAME_REGEX - Static variable in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
A non-capture group, for hfiles, so that this can be embedded.
- HFILE_ONHEAP_BLOCK_CACHE_FIXED_SIZE_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
- HFILE_ONHEAP_BLOCK_CACHE_FIXED_SIZE_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
Configuration key for setting the fix size of the block size, default do nothing and it should be explicitly set by user or only used within ClientSideRegionScanner.
- HFILE_PREAD_ALL_BYTES_ENABLED_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
- HFILE_PREAD_ALL_BYTES_ENABLED_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
Configuration key for setting pread must read both necessaryLen and extraLen, default is disabled.
- HFILE_REF_FAMILY - Static variable in class org.apache.hadoop.hbase.replication.TableReplicationQueueStorage
- org.apache.hadoop.hbase.io.hfile.HFile.CachingBlockReader - Interface in org.apache.hadoop.hbase.io.hfile
-
An abstraction used by the block index.
- org.apache.hadoop.hbase.io.hfile.HFile.Reader - Interface in org.apache.hadoop.hbase.io.hfile
-
An interface used by clients to open and iterate an
HFile
. - org.apache.hadoop.hbase.io.hfile.HFile.Writer - Interface in org.apache.hadoop.hbase.io.hfile
-
API required to write an
HFile
- org.apache.hadoop.hbase.io.hfile.HFile.WriterFactory - Class in org.apache.hadoop.hbase.io.hfile
-
This variety of ways to construct writers is used throughout the code, and we want to be able to swap writer implementations.
- org.apache.hadoop.hbase.backup.HFileArchiver - Class in org.apache.hadoop.hbase.backup
-
Utility class to handle the removal of HFiles (or the respective
StoreFiles
) for a HRegion from theFileSystem
. - org.apache.hadoop.hbase.util.HFileArchiveUtil - Class in org.apache.hadoop.hbase.util
-
Helper class for all utilities related to archival/retrieval of HFiles
- org.apache.hadoop.hbase.io.hfile.HFileBlock - Class in org.apache.hadoop.hbase.io.hfile
-
Cacheable Blocks of an
HFile
version 2 file. - HFileBlock(BlockType, int, int, long, ByteBuff, boolean, long, int, int, HFileContext, ByteBuffAllocator) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
Creates a new
HFile
block from the given fields. - HFILEBLOCK_DUMMY_HEADER - Static variable in class org.apache.hadoop.hbase.HConstants
-
Just an array of bytes of the right size.
- HFILEBLOCK_HEADER_SIZE - Static variable in class org.apache.hadoop.hbase.HConstants
-
The size of a version 2 HFile block header, minor version 1.
- HFILEBLOCK_HEADER_SIZE_NO_CHECKSUM - Static variable in class org.apache.hadoop.hbase.HConstants
-
The size data structures with minor version is 0
- org.apache.hadoop.hbase.io.hfile.HFileBlock.BlockDeserializer - Class in org.apache.hadoop.hbase.io.hfile
- org.apache.hadoop.hbase.io.hfile.HFileBlockBuilder - Class in org.apache.hadoop.hbase.io.hfile
- HFileBlockBuilder() - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileBlockBuilder
- org.apache.hadoop.hbase.io.encoding.HFileBlockDecodingContext - Interface in org.apache.hadoop.hbase.io.encoding
-
A decoding context that is created by a reader's encoder, and is shared across all of the reader's read operations.
- org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultDecodingContext - Class in org.apache.hadoop.hbase.io.encoding
-
A default implementation of
HFileBlockDecodingContext
. - HFileBlockDefaultDecodingContext(Configuration, HFileContext) - Constructor for class org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultDecodingContext
- org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultEncodingContext - Class in org.apache.hadoop.hbase.io.encoding
-
A default implementation of
HFileBlockEncodingContext
. - HFileBlockDefaultEncodingContext(Configuration, DataBlockEncoding, byte[], HFileContext) - Constructor for class org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultEncodingContext
- org.apache.hadoop.hbase.io.encoding.HFileBlockEncodingContext - Interface in org.apache.hadoop.hbase.io.encoding
-
An encoding context that is created by a writer's encoder, and is shared across the writer's whole lifetime.
- org.apache.hadoop.hbase.io.hfile.HFileBlockIndex - Class in org.apache.hadoop.hbase.io.hfile
-
Provides functionality to write (
HFileBlockIndex.BlockIndexWriter
) and read BlockIndexReader single-level and multi-level block indexes. - HFileBlockIndex() - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex
- org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexWriter - Class in org.apache.hadoop.hbase.io.hfile
-
Writes the block index into the output stream.
- hfileContext - Variable in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
- hFileContext - Variable in class org.apache.hadoop.hbase.io.hfile.HFileWriterImpl
- org.apache.hadoop.hbase.io.hfile.HFileContext - Class in org.apache.hadoop.hbase.io.hfile
-
Read-only HFile Context Information.
- HFileContext() - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileContext
- HFileContext(HFileContext) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileContext
-
Copy constructor
- org.apache.hadoop.hbase.io.hfile.HFileContextBuilder - Class in org.apache.hadoop.hbase.io.hfile
-
A builder that helps in building up the HFileContext
- HFileContextBuilder() - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileContextBuilder
- HFileContextBuilder(HFileContext) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileContextBuilder
-
Use this constructor if you want to change a few settings only in another context.
- org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker - Class in org.apache.hadoop.hbase.util.hbck
-
This class marches through all of the region's hfiles and verifies that they are all valid files.
- HFileCorruptionChecker(Configuration, ExecutorService, boolean) - Constructor for class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
- org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoder - Interface in org.apache.hadoop.hbase.io.hfile
-
Controls what kind of data block encoding is used.
- org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoderImpl - Class in org.apache.hadoop.hbase.io.hfile
-
Do different kinds of data block encoding according to column family options.
- HFileDataBlockEncoderImpl(DataBlockEncoding) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoderImpl
-
Do data block encoding with specified options.
- HFileFilter(FileSystem) - Constructor for class org.apache.hadoop.hbase.util.FSUtils.HFileFilter
- org.apache.hadoop.hbase.io.hfile.HFileIndexBlockEncoder - Interface in org.apache.hadoop.hbase.io.hfile
-
Controls what kind of index block encoding is used.
- org.apache.hadoop.hbase.io.hfile.HFileIndexBlockEncoder.EncodedSeeker - Interface in org.apache.hadoop.hbase.io.hfile
- org.apache.hadoop.hbase.io.hfile.HFileIndexBlockEncoderImpl - Class in org.apache.hadoop.hbase.io.hfile
-
Do different kinds of index block encoding according to column family options.
- HFileIndexBlockEncoderImpl(IndexBlockEncoding) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileIndexBlockEncoderImpl
-
Do index block encoding with specified options.
- org.apache.hadoop.hbase.io.hfile.HFileInfo - Class in org.apache.hadoop.hbase.io.hfile
-
Metadata Map of attributes for HFile written out as HFile Trailer.
- HFileInfo() - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileInfo
- HFileInfo(ReaderContext, Configuration) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileInfo
- org.apache.hadoop.hbase.mapreduce.HFileInputFormat - Class in org.apache.hadoop.hbase.mapreduce
-
Simple MR input format for HFiles.
- HFileInputFormat() - Constructor for class org.apache.hadoop.hbase.mapreduce.HFileInputFormat
- org.apache.hadoop.hbase.io.HFileLink - Class in org.apache.hadoop.hbase.io
-
HFileLink describes a link to an hfile.
- HFileLink(Path, Path, Path, Path) - Constructor for class org.apache.hadoop.hbase.io.HFileLink
-
Dead simple hfile link constructor
- HFileLinkFilter() - Constructor for class org.apache.hadoop.hbase.util.FSUtils.HFileLinkFilter
- org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2 - Class in org.apache.hadoop.hbase.mapreduce
-
Writes HFiles.
- HFileOutputFormat2() - Constructor for class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
- org.apache.hadoop.hbase.HFilePerformanceEvaluation - Class in org.apache.hadoop.hbase
-
This class runs performance benchmarks for
HFile
. - HFilePerformanceEvaluation() - Constructor for class org.apache.hadoop.hbase.HFilePerformanceEvaluation
- org.apache.hadoop.hbase.io.hfile.HFilePreadReader - Class in org.apache.hadoop.hbase.io.hfile
-
Implementation of
HFile.Reader
to deal with pread. - HFilePreadReader(ReaderContext, HFileInfo, CacheConfig, Configuration) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFilePreadReader
- org.apache.hadoop.hbase.io.hfile.HFilePrettyPrinter - Class in org.apache.hadoop.hbase.io.hfile
-
Implements pretty-printing functionality for
HFile
s. - HFilePrettyPrinter() - Constructor for class org.apache.hadoop.hbase.io.hfile.HFilePrettyPrinter
- HFilePrettyPrinter(Configuration) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFilePrettyPrinter
- org.apache.hadoop.hbase.io.hfile.HFileReaderImpl - Class in org.apache.hadoop.hbase.io.hfile
-
Implementation that can handle all hfile versions of
HFile.Reader
. - HFileReaderImpl(ReaderContext, HFileInfo, CacheConfig, Configuration) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
-
Opens a HFile.
- org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.BlockIndexNotLoadedException - Exception in org.apache.hadoop.hbase.io.hfile
- org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.EncodedScanner - Class in org.apache.hadoop.hbase.io.hfile
-
Scanner that operates on encoded data blocks.
- org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl - Class in org.apache.hadoop.hbase.io.hfile
- org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.NotSeekedException - Exception in org.apache.hadoop.hbase.io.hfile
-
An exception thrown when an operation requiring a scanner to be seeked is invoked on a scanner that is not seeked.
- hfileRefsZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZNodePaths
- org.apache.hadoop.hbase.io.hfile.HFileScanner - Interface in org.apache.hadoop.hbase.io.hfile
-
A scanner allows you to position yourself within a HFile and scan through it.
- HFileScannerImpl(HFile.Reader, boolean, boolean, boolean) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
- org.apache.hadoop.hbase.io.hfile.HFileStreamReader - Class in org.apache.hadoop.hbase.io.hfile
-
Implementation of
HFile.Reader
to deal with stream read do not perform any prefetch operations (HFilePreadReader will do this). - HFileStreamReader(ReaderContext, HFileInfo, CacheConfig, Configuration) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileStreamReader
- org.apache.hadoop.hbase.io.hfile.HFileWriterImpl - Class in org.apache.hadoop.hbase.io.hfile
-
Common functionality needed by all versions of
HFile
writers. - HFileWriterImpl(Configuration, CacheConfig, Path, FSDataOutputStream, HFileContext) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileWriterImpl
- HIDDEN_END_KEY - Static variable in class org.apache.hadoop.hbase.client.RegionInfoDisplay
- HIDDEN_START_KEY - Static variable in class org.apache.hadoop.hbase.client.RegionInfoDisplay
- hideCursor() - Method in class org.apache.hadoop.hbase.hbtop.screen.AbstractScreenView
- hideCursor() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.batch.BatchTerminal
- hideCursor() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.ScreenBuffer
- hideCursor() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.TerminalImpl
- hideCursor() - Method in interface org.apache.hadoop.hbase.hbtop.terminal.Terminal
- HIGH_QOS - Static variable in class org.apache.hadoop.hbase.HConstants
- higher(T) - Method in class org.apache.hadoop.hbase.regionserver.CellSet
- higherEntry(K) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
- higherEntry(T) - Method in class org.apache.hadoop.hbase.regionserver.CellFlatMap
- higherKey(K) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
- higherKey(T) - Method in class org.apache.hadoop.hbase.regionserver.CellFlatMap
- highestProcessedAppendTxid - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
- highestSyncedTxid - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
Updated to the transaction id of the last successful sync call.
- highestUnsyncedTxid - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
The highest known outstanding unsync'd WALEdit transaction id.
- hint - Variable in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
- org.apache.hadoop.hbase.filter.HintingFilter - Interface in org.apache.hadoop.hbase.filter
-
Marker interface for filters that may return SEEK_NEXT_USING_HINT.
- hist - Variable in class org.apache.hadoop.hbase.PerformanceEvaluation.RunResult
- histogram(String) - Method in interface org.apache.hadoop.hbase.metrics.MetricRegistry
-
Get or construct a
Histogram
used to measure a distribution of values. - org.apache.hadoop.hbase.metrics.Histogram - Interface in org.apache.hadoop.hbase.metrics
-
A metric which measures the distribution of values.
- HISTORICAL_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.HStoreFile
- HISTORY - Enum constant in enum class org.apache.hadoop.hbase.backup.BackupRestoreConstants.BackupCommand
- hit(boolean, boolean, BlockType) - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
- org.apache.hadoop.hbase.master.HMaster - Class in org.apache.hadoop.hbase.master
-
HMaster is the "master server" for HBase.
- HMaster(Configuration) - Constructor for class org.apache.hadoop.hbase.master.HMaster
-
Initializes the HMaster.
- org.apache.hadoop.hbase.master.HMaster.TableDescriptorGetter - Interface in org.apache.hadoop.hbase.master
-
Implement to return TableDescriptor after pre-checks
- org.apache.hadoop.hbase.master.HMasterCommandLine - Class in org.apache.hadoop.hbase.master
- HMasterCommandLine(Class<? extends HMaster>) - Constructor for class org.apache.hadoop.hbase.master.HMasterCommandLine
- org.apache.hadoop.hbase.master.HMasterCommandLine.LocalHMaster - Class in org.apache.hadoop.hbase.master
- org.apache.hadoop.hbase.regionserver.HMobStore - Class in org.apache.hadoop.hbase.regionserver
-
The store implementation to save MOBs (medium objects), it extends the HStore.
- HMobStore(HRegion, ColumnFamilyDescriptor, Configuration, boolean) - Constructor for class org.apache.hadoop.hbase.regionserver.HMobStore
- HOLE_IN_REGION_CHAIN - Enum constant in enum class org.apache.hadoop.hbase.util.HbckErrorReporter.ERROR_CODE
-
Deprecated.
- HOLES - Static variable in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
- HOLES_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
- home() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.InputModeScreenPresenter
- home() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenPresenter
- Home - Enum constant in enum class org.apache.hadoop.hbase.hbtop.terminal.KeyPress.Type
- host - Static variable in class org.apache.hadoop.hbase.thrift.DemoClient
- host - Static variable in class org.apache.hadoop.hbase.thrift.HttpDoAsClient
- host - Variable in class org.apache.hadoop.hbase.thrift.ThriftServer
- HOST - Static variable in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
- HostAndWeight(String, long, long) - Constructor for class org.apache.hadoop.hbase.HDFSBlocksDistribution.HostAndWeight
-
Constructor
- hostName(String) - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
-
Set the hostname of the http server.
- HOSTNAME_PORT_SEPARATOR - Static variable in class org.apache.hadoop.hbase.util.Addressing
- HOUR_IN_SECONDS - Static variable in class org.apache.hadoop.hbase.HConstants
- org.apache.hadoop.hbase.zookeeper.HQuorumPeer - Class in org.apache.hadoop.hbase.zookeeper
-
HBase's version of ZooKeeper's QuorumPeer.
- org.apache.hadoop.hbase.regionserver.HRegion - Class in org.apache.hadoop.hbase.regionserver
-
Regions store data for a certain region of a table.
- HRegion(Path, WAL, FileSystem, Configuration, RegionInfo, TableDescriptor, RegionServerServices) - Constructor for class org.apache.hadoop.hbase.regionserver.HRegion
-
Deprecated.Use other constructors.
- HRegion(HRegionFileSystem, WAL, Configuration, TableDescriptor, RegionServerServices) - Constructor for class org.apache.hadoop.hbase.regionserver.HRegion
-
HRegion constructor.
- HREGION_COLUMNFAMILY_FLUSH_SIZE_LOWER_BOUND - Static variable in class org.apache.hadoop.hbase.regionserver.FlushLargeStoresPolicy
- HREGION_COLUMNFAMILY_FLUSH_SIZE_LOWER_BOUND_MIN - Static variable in class org.apache.hadoop.hbase.regionserver.FlushLargeStoresPolicy
- HREGION_COMPACTIONDIR_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
-
Used to construct the name of the compaction directory during compaction
- HREGION_EDITS_REPLAY_SKIP_ERRORS - Static variable in class org.apache.hadoop.hbase.HConstants
- HREGION_LOGDIR_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
-
Used to construct the name of the log directory for a region server
- HREGION_MAX_FILESIZE - Static variable in class org.apache.hadoop.hbase.HConstants
-
Conf key for the max file size after which we split the region
- HREGION_MEMSTORE_BLOCK_MULTIPLIER - Static variable in class org.apache.hadoop.hbase.HConstants
-
Block updates if memstore has hbase.hregion.memstore.block.multiplier times hbase.hregion.memstore.flush.size bytes.
- HREGION_MEMSTORE_FLUSH_SIZE - Static variable in class org.apache.hadoop.hbase.HConstants
-
Conf key for the memstore size at which we flush the memstore
- HREGION_OLDLOGDIR_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
-
Like the previous, but for old logs that are about to be deleted
- HREGION_VERSION - Static variable in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
- org.apache.hadoop.hbase.regionserver.HRegion.BulkLoadListener - Interface in org.apache.hadoop.hbase.regionserver
-
Listener class to enable callers of bulkLoadHFile() to perform any necessary pre/post processing of a given bulkload call
- org.apache.hadoop.hbase.regionserver.HRegion.FlushResult - Interface in org.apache.hadoop.hbase.regionserver
- org.apache.hadoop.hbase.regionserver.HRegion.FlushResult.Result - Enum Class in org.apache.hadoop.hbase.regionserver
- org.apache.hadoop.hbase.regionserver.HRegion.FlushResultImpl - Class in org.apache.hadoop.hbase.regionserver
-
Objects from this class are created when flushing to describe all the different states that that method ends up in.
- org.apache.hadoop.hbase.regionserver.HRegion.PrepareFlushResult - Class in org.apache.hadoop.hbase.regionserver
-
A result object from prepare flush cache stage
- org.apache.hadoop.hbase.regionserver.HRegion.RowLockImpl - Class in org.apache.hadoop.hbase.regionserver
-
Class used to represent a lock on a row.
- org.apache.hadoop.hbase.regionserver.HRegionFileSystem - Class in org.apache.hadoop.hbase.regionserver
-
View to an on-disk Region.
- org.apache.hadoop.hbase.HRegionLocation - Class in org.apache.hadoop.hbase
-
Data structure to hold RegionInfo and the address for the hosting HRegionServer.
- HRegionLocation(RegionInfo, ServerName) - Constructor for class org.apache.hadoop.hbase.HRegionLocation
- HRegionLocation(RegionInfo, ServerName, long) - Constructor for class org.apache.hadoop.hbase.HRegionLocation
- HRegionMetricsWrapperRunnable() - Constructor for class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl.HRegionMetricsWrapperRunnable
- org.apache.hadoop.hbase.mapred.HRegionPartitioner<K2,
V2> - Class in org.apache.hadoop.hbase.mapred -
This is used to partition the output keys into groups of keys.
- org.apache.hadoop.hbase.mapreduce.HRegionPartitioner<KEY,
VALUE> - Class in org.apache.hadoop.hbase.mapreduce -
This is used to partition the output keys into groups of keys.
- HRegionPartitioner() - Constructor for class org.apache.hadoop.hbase.mapred.HRegionPartitioner
- HRegionPartitioner() - Constructor for class org.apache.hadoop.hbase.mapreduce.HRegionPartitioner
- org.apache.hadoop.hbase.regionserver.HRegionServer - Class in org.apache.hadoop.hbase.regionserver
-
HRegionServer makes a set of HRegions available to clients.
- HRegionServer(Configuration) - Constructor for class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Starts a HRegionServer at the default location.
- org.apache.hadoop.hbase.regionserver.HRegionServerCommandLine - Class in org.apache.hadoop.hbase.regionserver
-
Class responsible for parsing the command line and starting the RegionServer.
- HRegionServerCommandLine(Class<? extends HRegionServer>) - Constructor for class org.apache.hadoop.hbase.regionserver.HRegionServerCommandLine
- org.apache.hadoop.hbase.regionserver.HRegionWALFileSystem - Class in org.apache.hadoop.hbase.regionserver
-
A Wrapper for the region FileSystem operations adding WAL specific operations
- HS_HA - Enum constant in enum class org.apache.hadoop.hbase.thrift.ImplType
- org.apache.hadoop.hbase.regionserver.HStore - Class in org.apache.hadoop.hbase.regionserver
-
A Store holds a column family in a Region.
- HStore(HRegion, ColumnFamilyDescriptor, Configuration, boolean) - Constructor for class org.apache.hadoop.hbase.regionserver.HStore
-
Constructor
- HSTORE_OPEN_AND_CLOSE_THREADS_MAX - Static variable in class org.apache.hadoop.hbase.HConstants
-
The max number of threads used for opening and closing stores or store files in parallel
- org.apache.hadoop.hbase.regionserver.HStoreFile - Class in org.apache.hadoop.hbase.regionserver
-
A Store data file.
- HStoreFile(FileSystem, Path, Configuration, CacheConfig, BloomType, boolean, StoreFileTracker) - Constructor for class org.apache.hadoop.hbase.regionserver.HStoreFile
-
Constructor, loads a reader and it's indices, etc.
- HStoreFile(StoreFileInfo, BloomType, CacheConfig) - Constructor for class org.apache.hadoop.hbase.regionserver.HStoreFile
-
Constructor, loads a reader and it's indices, etc.
- HStoreFile(StoreFileInfo, BloomType, CacheConfig, BloomFilterMetrics) - Constructor for class org.apache.hadoop.hbase.regionserver.HStoreFile
-
Constructor, loads a reader and it's indices, etc.
- org.apache.hadoop.hbase.thrift.HThreadedSelectorServerArgs - Class in org.apache.hadoop.hbase.thrift
-
A TThreadedSelectorServer.Args that reads hadoop configuration
- HThreadedSelectorServerArgs(TNonblockingServerTransport, Configuration) - Constructor for class org.apache.hadoop.hbase.thrift.HThreadedSelectorServerArgs
- org.apache.hadoop.hbase.http.HtmlQuoting - Class in org.apache.hadoop.hbase.http
-
This class is responsible for quoting HTML characters.
- HTTP_AND_HTTPS - Enum constant in enum class org.apache.hadoop.hbase.http.HttpConfig.Policy
- HTTP_AUTHENTICATION_SIGNATURE_SECRET_FILE_KEY - Static variable in class org.apache.hadoop.hbase.http.HttpServer
- HTTP_MAX_THREADS_KEY - Static variable in class org.apache.hadoop.hbase.thrift.Constants
- HTTP_MAX_THREADS_KEY_DEFAULT - Static variable in class org.apache.hadoop.hbase.thrift.Constants
- HTTP_MIN_THREADS_KEY - Static variable in class org.apache.hadoop.hbase.thrift.Constants
- HTTP_MIN_THREADS_KEY_DEFAULT - Static variable in class org.apache.hadoop.hbase.thrift.Constants
- HTTP_ONLY - Enum constant in enum class org.apache.hadoop.hbase.http.HttpConfig.Policy
- HTTP_PRIVILEGED_CONF_DEFAULT - Static variable in class org.apache.hadoop.hbase.http.HttpServer
- HTTP_PRIVILEGED_CONF_KEY - Static variable in class org.apache.hadoop.hbase.http.HttpServer
- HTTP_SPNEGO_AUTHENTICATION_ADMIN_GROUPS_KEY - Static variable in class org.apache.hadoop.hbase.http.HttpServer
- HTTP_SPNEGO_AUTHENTICATION_ADMIN_USERS_KEY - Static variable in class org.apache.hadoop.hbase.http.HttpServer
- HTTP_SPNEGO_AUTHENTICATION_KEYTAB_KEY - Static variable in class org.apache.hadoop.hbase.http.HttpServer
- HTTP_SPNEGO_AUTHENTICATION_KRB_NAME_KEY - Static variable in class org.apache.hadoop.hbase.http.HttpServer
- HTTP_SPNEGO_AUTHENTICATION_PRINCIPAL_KEY - Static variable in class org.apache.hadoop.hbase.http.HttpServer
- HTTP_SPNEGO_AUTHENTICATION_PROXYUSER_ENABLE_DEFAULT - Static variable in class org.apache.hadoop.hbase.http.HttpServer
- HTTP_SPNEGO_AUTHENTICATION_PROXYUSER_ENABLE_KEY - Static variable in class org.apache.hadoop.hbase.http.HttpServer
- HTTP_UI_AUTHENTICATION - Static variable in class org.apache.hadoop.hbase.http.HttpServer
- HTTP_UI_NO_CACHE_ENABLE_KEY - Static variable in class org.apache.hadoop.hbase.http.HttpServer
- HTTP_UI_SHOW_STACKTRACE_KEY - Static variable in class org.apache.hadoop.hbase.http.HttpServer
- org.apache.hadoop.hbase.thrift.HttpAuthenticationException - Exception in org.apache.hadoop.hbase.thrift
- HttpAuthenticationException(String) - Constructor for exception org.apache.hadoop.hbase.thrift.HttpAuthenticationException
- HttpAuthenticationException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.thrift.HttpAuthenticationException
- HttpAuthenticationException(Throwable) - Constructor for exception org.apache.hadoop.hbase.thrift.HttpAuthenticationException
- org.apache.hadoop.hbase.http.HttpConfig - Class in org.apache.hadoop.hbase.http
-
Statics to get access to Http related configuration.
- HttpConfig(Configuration) - Constructor for class org.apache.hadoop.hbase.http.HttpConfig
- org.apache.hadoop.hbase.http.HttpConfig.Policy - Enum Class in org.apache.hadoop.hbase.http
- org.apache.hadoop.hbase.thrift.HttpDoAsClient - Class in org.apache.hadoop.hbase.thrift
-
See the instructions under hbase-examples/README.txt
- httpEnabled - Variable in class org.apache.hadoop.hbase.thrift.ThriftServer
- org.apache.hadoop.hbase.client.example.HttpProxyExample - Class in org.apache.hadoop.hbase.client.example
-
A simple example on how to use
AsyncTable
to write a fully asynchronous HTTP proxy server. - HttpProxyExample(Configuration, int) - Constructor for class org.apache.hadoop.hbase.client.example.HttpProxyExample
- org.apache.hadoop.hbase.http.HttpRequestLog - Class in org.apache.hadoop.hbase.http
-
RequestLog object for use with Http
- HTTPS_ONLY - Enum constant in enum class org.apache.hadoop.hbase.http.HttpConfig.Policy
- httpServer - Variable in class org.apache.hadoop.hbase.thrift.ThriftServer
- org.apache.hadoop.hbase.http.HttpServer - Class in org.apache.hadoop.hbase.http
-
Create a Jetty embedded server to answer http requests.
- HttpServer(String, String, int, boolean) - Constructor for class org.apache.hadoop.hbase.http.HttpServer
-
Deprecated.Since 0.99.0
- HttpServer(String, String, int, boolean, Configuration) - Constructor for class org.apache.hadoop.hbase.http.HttpServer
-
Deprecated.Since 0.99.0
- HttpServer(String, String, int, boolean, Configuration, String[]) - Constructor for class org.apache.hadoop.hbase.http.HttpServer
-
Deprecated.Since 0.99.0
- HttpServer(String, String, int, boolean, Configuration, AccessControlList) - Constructor for class org.apache.hadoop.hbase.http.HttpServer
-
Deprecated.Since 0.99.0
- HttpServer(String, String, int, boolean, Configuration, AccessControlList, String[]) - Constructor for class org.apache.hadoop.hbase.http.HttpServer
-
Deprecated.Since 0.99.0
- org.apache.hadoop.hbase.http.HttpServer.Builder - Class in org.apache.hadoop.hbase.http
-
Class to construct instances of HTTP server with specific options.
- org.apache.hadoop.hbase.http.HttpServer.QuotingInputFilter - Class in org.apache.hadoop.hbase.http
-
A Servlet input filter that quotes all HTML active characters in the parameter names and values.
- org.apache.hadoop.hbase.http.HttpServer.QuotingInputFilter.RequestQuoter - Class in org.apache.hadoop.hbase.http
- org.apache.hadoop.hbase.http.HttpServer.StackServlet - Class in org.apache.hadoop.hbase.http
-
A very simple servlet to serve up a text representation of the current stack traces.
- org.apache.hadoop.hbase.http.HttpServerUtil - Class in org.apache.hadoop.hbase.http
-
HttpServer utility.
- httpUGI - Variable in class org.apache.hadoop.hbase.thrift.ThriftServer
- humanReadableTimestamp(long) - Static method in class org.apache.hadoop.hbase.KeyValue
I
- I - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
ASCII code for 'I'
- id - Variable in class org.apache.hadoop.hbase.ipc.ServerCall
- ID_ATRIBUTE - Static variable in class org.apache.hadoop.hbase.client.OperationWithAttributes
- ID_SIZE - Static variable in enum class org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
- ID_SIZE - Static variable in enum class org.apache.hadoop.hbase.io.encoding.IndexBlockEncoding
- idealMaxKeys(long, double) - 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 maintain the given error rate, assuming the number of hash functions is chosen optimally and does not even have to be an integer (hence the "ideal" in the function name).
- org.apache.hadoop.hbase.mapred.IdentityTableMap - Class in org.apache.hadoop.hbase.mapred
-
Pass the given key and record as-is to reduce
- IdentityTableMap() - Constructor for class org.apache.hadoop.hbase.mapred.IdentityTableMap
-
constructor
- org.apache.hadoop.hbase.mapreduce.IdentityTableMapper - Class in org.apache.hadoop.hbase.mapreduce
-
Pass the given key and record as-is to the reduce phase.
- IdentityTableMapper() - Constructor for class org.apache.hadoop.hbase.mapreduce.IdentityTableMapper
- org.apache.hadoop.hbase.mapred.IdentityTableReduce - Class in org.apache.hadoop.hbase.mapred
-
Write to table each key, record pair
- IdentityTableReduce() - Constructor for class org.apache.hadoop.hbase.mapred.IdentityTableReduce
- org.apache.hadoop.hbase.mapreduce.IdentityTableReducer - Class in org.apache.hadoop.hbase.mapreduce
-
Convenience class that simply writes all values (which must be
Put
orDelete
instances) passed to it out to the configured HBase table. - IdentityTableReducer() - Constructor for class org.apache.hadoop.hbase.mapreduce.IdentityTableReducer
- IDLE_TIME - Static variable in interface org.apache.hadoop.hbase.ipc.RpcClient
- org.apache.hadoop.hbase.util.IdLock - Class in org.apache.hadoop.hbase.util
-
Allows multiple concurrent clients to lock on a numeric id with a minimal memory overhead.
- IdLock() - Constructor for class org.apache.hadoop.hbase.util.IdLock
- org.apache.hadoop.hbase.util.IdLock.Entry - Class in org.apache.hadoop.hbase.util
-
An entry returned to the client as a lock object
- org.apache.hadoop.hbase.util.IdReadWriteLock<T> - Class in org.apache.hadoop.hbase.util
-
Allows multiple concurrent clients to lock on a numeric id with ReentrantReadWriteLock.
- IdReadWriteLock() - Constructor for class org.apache.hadoop.hbase.util.IdReadWriteLock
- org.apache.hadoop.hbase.util.IdReadWriteLockStrongRef<T> - Class in org.apache.hadoop.hbase.util
- IdReadWriteLockStrongRef() - Constructor for class org.apache.hadoop.hbase.util.IdReadWriteLockStrongRef
- org.apache.hadoop.hbase.util.IdReadWriteLockWithObjectPool<T> - Class in org.apache.hadoop.hbase.util
- IdReadWriteLockWithObjectPool() - Constructor for class org.apache.hadoop.hbase.util.IdReadWriteLockWithObjectPool
- IdReadWriteLockWithObjectPool(IdReadWriteLockWithObjectPool.ReferenceType) - Constructor for class org.apache.hadoop.hbase.util.IdReadWriteLockWithObjectPool
-
Constructor of IdReadWriteLockWithObjectPool
- org.apache.hadoop.hbase.util.IdReadWriteLockWithObjectPool.ReferenceType - Enum Class in org.apache.hadoop.hbase.util
- idx - Variable in class org.apache.hadoop.hbase.types.StructIterator
- ifEquals(byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncTable.CheckAndMutateBuilder
-
Deprecated.Check for equality.
- ifEquals(byte[]) - Method in interface org.apache.hadoop.hbase.client.Table.CheckAndMutateBuilder
-
Deprecated.Check for equality.
- ifEquals(byte[], byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.CheckAndMutate.Builder
-
Check for equality
- ifMatches(byte[], byte[], CompareOperator, byte[]) - Method in class org.apache.hadoop.hbase.client.CheckAndMutate.Builder
-
Check for match
- ifMatches(CompareOperator, byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncTable.CheckAndMutateBuilder
-
Deprecated.Compare a value
- ifMatches(CompareOperator, byte[]) - Method in interface org.apache.hadoop.hbase.client.Table.CheckAndMutateBuilder
-
Deprecated.Check for match.
- ifMatches(Filter) - Method in class org.apache.hadoop.hbase.client.CheckAndMutate.Builder
-
Check for match
- ifNotExists() - Method in interface org.apache.hadoop.hbase.client.AsyncTable.CheckAndMutateBuilder
-
Deprecated.Check for lack of column.
- ifNotExists() - Method in interface org.apache.hadoop.hbase.client.Table.CheckAndMutateBuilder
-
Deprecated.Check for lack of column.
- ifNotExists(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.CheckAndMutate.Builder
-
Check for lack of column
- IGNORE_MISSING_FILES - Static variable in class org.apache.hadoop.hbase.mapreduce.WALPlayer
- ignoreConflicts - Variable in class org.apache.hadoop.hbase.util.LoadTestTool
- ignoreZKDeleteForTesting - Variable in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
- org.apache.hadoop.hbase.exceptions.IllegalArgumentIOException - Exception in org.apache.hadoop.hbase.exceptions
-
Exception thrown when an illegal argument is passed to a function/procedure.
- IllegalArgumentIOException() - Constructor for exception org.apache.hadoop.hbase.exceptions.IllegalArgumentIOException
- IllegalArgumentIOException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.IllegalArgumentIOException
- IllegalArgumentIOException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.exceptions.IllegalArgumentIOException
- IllegalArgumentIOException(Throwable) - Constructor for exception org.apache.hadoop.hbase.exceptions.IllegalArgumentIOException
- org.apache.hadoop.hbase.util.ImmutableByteArray - Class in org.apache.hadoop.hbase.util
-
Mainly used as keys for HashMap.
- org.apache.hadoop.hbase.io.ImmutableBytesWritable - Class in org.apache.hadoop.hbase.io
-
A byte sequence that is usable as a key or value.
- ImmutableBytesWritable() - Constructor for class org.apache.hadoop.hbase.io.ImmutableBytesWritable
-
Create a zero-size sequence.
- ImmutableBytesWritable(byte[]) - Constructor for class org.apache.hadoop.hbase.io.ImmutableBytesWritable
-
Create a ImmutableBytesWritable using the byte array as the initial value.
- ImmutableBytesWritable(byte[], int, int) - Constructor for class org.apache.hadoop.hbase.io.ImmutableBytesWritable
-
Set the value to a given byte range
- ImmutableBytesWritable(ImmutableBytesWritable) - Constructor for class org.apache.hadoop.hbase.io.ImmutableBytesWritable
-
Set the new ImmutableBytesWritable to the contents of the passed
ibw
. - org.apache.hadoop.hbase.io.ImmutableBytesWritable.Comparator - Class in org.apache.hadoop.hbase.io
-
A Comparator optimized for ImmutableBytesWritable.
- org.apache.hadoop.hbase.regionserver.ImmutableMemStoreLAB - Class in org.apache.hadoop.hbase.regionserver
-
A MemStoreLAB implementation which wraps N MemStoreLABs.
- ImmutableMemStoreLAB(List<MemStoreLAB>) - Constructor for class org.apache.hadoop.hbase.regionserver.ImmutableMemStoreLAB
- org.apache.hadoop.hbase.client.ImmutableScan - Class in org.apache.hadoop.hbase.client
-
Immutable version of Scan
- ImmutableScan(Scan) - Constructor for class org.apache.hadoop.hbase.client.ImmutableScan
-
Create Immutable instance of Scan from given Scan object
- org.apache.hadoop.hbase.regionserver.ImmutableSegment - Class in org.apache.hadoop.hbase.regionserver
-
ImmutableSegment is an abstract class that extends the API supported by a
Segment
, and is not needed for aMutableSegment
. - ImmutableSegment(CellComparator) - Constructor for class org.apache.hadoop.hbase.regionserver.ImmutableSegment
-
------------------------------------------------------------------------ Empty C-tor to be used only for CompositeImmutableSegment
- ImmutableSegment(CellComparator, List<ImmutableSegment>) - Constructor for class org.apache.hadoop.hbase.regionserver.ImmutableSegment
- ImmutableSegment(CellSet, CellComparator, MemStoreLAB) - Constructor for class org.apache.hadoop.hbase.regionserver.ImmutableSegment
-
------------------------------------------------------------------------ C-tor to be used to build the derived classes
- ImmutableSegment(Segment) - Constructor for class org.apache.hadoop.hbase.regionserver.ImmutableSegment
-
------------------------------------------------------------------------ Copy C-tor to be used when new CSLMImmutableSegment (derived) is being built from a Mutable one.
- impl - Variable in class org.apache.hadoop.hbase.coprocessor.BaseEnvironment
-
The coprocessor
- implClassName - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
The class name of the runtime implementation, used as prefix for logging/tracing.
- implementationClassName(String) - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
-
Deprecated.Since 3.0.0, will be removed in 4.0.0. You can not set it any more as the implementation has to use too many internal stuffs in HBase.
- org.apache.hadoop.hbase.thrift.ImplType - Enum Class in org.apache.hadoop.hbase.thrift
-
An enum of server implementation selections
- org.apache.hadoop.hbase.mapreduce.Import - Class in org.apache.hadoop.hbase.mapreduce
-
Import data written by
Export
. - Import() - Constructor for class org.apache.hadoop.hbase.mapreduce.Import
- IMPORT_FORMAT_VER - Static variable in class org.apache.hadoop.hbase.mapreduce.ResultSerialization
- org.apache.hadoop.hbase.mapreduce.Import.CellImporter - Class in org.apache.hadoop.hbase.mapreduce
-
A mapper that just writes out KeyValues.
- org.apache.hadoop.hbase.mapreduce.Import.CellReducer - Class in org.apache.hadoop.hbase.mapreduce
- org.apache.hadoop.hbase.mapreduce.Import.CellSortImporter - Class in org.apache.hadoop.hbase.mapreduce
- org.apache.hadoop.hbase.mapreduce.Import.CellWritableComparable - Class in org.apache.hadoop.hbase.mapreduce
- org.apache.hadoop.hbase.mapreduce.Import.CellWritableComparable.CellWritableComparator - Class in org.apache.hadoop.hbase.mapreduce
- org.apache.hadoop.hbase.mapreduce.Import.CellWritableComparablePartitioner - Class in org.apache.hadoop.hbase.mapreduce
- org.apache.hadoop.hbase.mapreduce.Import.Importer - Class in org.apache.hadoop.hbase.mapreduce
-
Write table content out to files in hdfs.
- Importer() - Constructor for class org.apache.hadoop.hbase.mapreduce.Import.Importer
- org.apache.hadoop.hbase.mapreduce.ImportTsv - Class in org.apache.hadoop.hbase.mapreduce
-
Tool to import data from a TSV file.
- ImportTsv() - Constructor for class org.apache.hadoop.hbase.mapreduce.ImportTsv
- org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser - Class in org.apache.hadoop.hbase.mapreduce
- org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser.BadTsvLineException - Exception in org.apache.hadoop.hbase.mapreduce
- in - Variable in class org.apache.hadoop.hbase.codec.BaseDecoder
- IN_MEMORY - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
- IN_MEMORY - Static variable in class org.apache.hadoop.hbase.HConstants
- IN_MEMORY_COMPACTION - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
- IN_MEMORY_CONPACTION_POOL_SIZE_DEFAULT - Static variable in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
- IN_MEMORY_CONPACTION_POOL_SIZE_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
- IN_MEMORY_FLUSH_THRESHOLD_FACTOR_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
- IN_PROGRESS - Enum constant in enum class org.apache.hadoop.hbase.master.SplitLogManager.TerminationStatus
-
Deprecated.
- INC_BLOCKCACHE_TUNING_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSource
- INC_BLOCKCACHE_TUNING_NAME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSource
- INC_MEMSTORE_TUNING_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSource
- INC_MEMSTORE_TUNING_NAME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSource
- incActiveWorkerCount() - Method in interface org.apache.hadoop.hbase.thrift.MetricsThriftServerSource
-
Increment number of active thrift workers.
- incActiveWorkerCount() - Method in class org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceImpl
- incActiveWorkerCount() - Method in class org.apache.hadoop.hbase.thrift.ThriftMetrics
- incarnation - Variable in class org.apache.hadoop.hbase.master.SplitLogManager.Task
-
Deprecated.
- incCall(long) - Method in interface org.apache.hadoop.hbase.thrift.MetricsThriftServerSource
-
Add how long a call took
- incCall(long) - Method in class org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceImpl
- incCounters(String, long) - Method in interface org.apache.hadoop.hbase.metrics.BaseSource
-
Add some amount to a counter.
- incCounters(String, long) - Method in class org.apache.hadoop.hbase.metrics.BaseSourceImpl
-
Increment a named counter by some value.
- incGauge(String, long) - Method in interface org.apache.hadoop.hbase.metrics.BaseSource
-
Add some amount to a gauge.
- incGauge(String, long) - Method in class org.apache.hadoop.hbase.metrics.BaseSourceImpl
-
Add some amount to a gauge.
- incGlobalMemStoreSize(long, long, long) - Method in class org.apache.hadoop.hbase.regionserver.RegionServerAccounting
- incInfoThresholdExceeded(int) - Method in interface org.apache.hadoop.hbase.metrics.JvmPauseMonitorSource
-
Increment the INFO level threshold exceeded count
- incInfoThresholdExceeded(int) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
- incInfoThresholdExceeded(int) - Method in class org.apache.hadoop.hbase.rest.MetricsRESTSourceImpl
- incInfoThresholdExceeded(int) - Method in class org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceImpl
- INCLUDE - Enum constant in enum class org.apache.hadoop.hbase.client.RequestController.ReturnCode
-
Accept current row.
- INCLUDE - Enum constant in enum class org.apache.hadoop.hbase.filter.Filter.ReturnCode
-
Include the Cell
- INCLUDE - Enum constant in enum class org.apache.hadoop.hbase.filter.FilterWrapper.FilterRowRetCode
- INCLUDE - Enum constant in enum class org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher.MatchCode
-
Include KeyValue in the returned result
- INCLUDE_AND_NEXT_COL - Enum constant in enum class org.apache.hadoop.hbase.filter.Filter.ReturnCode
-
Include the Cell and seek to the next column skipping older versions.
- INCLUDE_AND_SEEK_NEXT_COL - Enum constant in enum class org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher.MatchCode
-
Include KeyValue and done with column, seek to next.
- INCLUDE_AND_SEEK_NEXT_ROW - Enum constant in enum class org.apache.hadoop.hbase.filter.Filter.ReturnCode
-
Include KeyValue and done with row, seek to next.
- INCLUDE_AND_SEEK_NEXT_ROW - Enum constant in enum class org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher.MatchCode
-
Include KeyValue and done with row, seek to next.
- INCLUDE_THIS_FAMILY - Enum constant in enum class org.apache.hadoop.hbase.filter.FilterWrapper.FilterRowRetCode
- org.apache.hadoop.hbase.regionserver.querymatcher.IncludeAllCompactionQueryMatcher - Class in org.apache.hadoop.hbase.regionserver.querymatcher
-
A compaction query matcher that always return INCLUDE and drops nothing.
- IncludeAllCompactionQueryMatcher(ScanInfo, DeleteTracker, ColumnTracker, long, long, long) - Constructor for class org.apache.hadoop.hbase.regionserver.querymatcher.IncludeAllCompactionQueryMatcher
- includeMVCCReadpoint() - Method in class org.apache.hadoop.hbase.regionserver.CreateStoreFileWriterParams
- includeMVCCReadpoint(boolean) - Method in class org.apache.hadoop.hbase.regionserver.CreateStoreFileWriterParams
-
Whether to include MVCC or not
- includeRegionInSplit(byte[], byte[]) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableInputFormatBase
-
Test if the given region is to be included in the InputSplit while splitting the regions of a table.
- includeRegionInSplit(byte[], byte[]) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
Test if the given region is to be included in the InputSplit while splitting the regions of a table.
- includesMvcc() - Method in class org.apache.hadoop.hbase.io.encoding.AbstractDataBlockEncoder.AbstractEncodedSeeker
- includesTag() - Method in class org.apache.hadoop.hbase.regionserver.CreateStoreFileWriterParams
- includesTag(boolean) - Method in class org.apache.hadoop.hbase.regionserver.CreateStoreFileWriterParams
-
Whether to includesTag or not
- includesTags() - Method in class org.apache.hadoop.hbase.io.encoding.AbstractDataBlockEncoder.AbstractEncodedSeeker
- includeStartRow() - Method in class org.apache.hadoop.hbase.client.ImmutableScan
- includeStartRow() - Method in class org.apache.hadoop.hbase.client.Scan
-
Returns if we should include start row when scan
- includesTimeRange(TimeRange) - Method in class org.apache.hadoop.hbase.io.TimeRange
-
Check if the range has any overlap with TimeRange
- includesTimeRange(TimeRange) - Method in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker
-
Check if the range has ANY overlap with TimeRange
- includeStopRow() - Method in class org.apache.hadoop.hbase.client.ImmutableScan
- includeStopRow() - Method in class org.apache.hadoop.hbase.client.Scan
-
Returns if we should include stop row when scan
- includeTable(TableName) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- includeTimestamp(ExtendedCell) - Method in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker
-
Update the current TimestampRange to include the timestamp from
cell
. - org.apache.hadoop.hbase.io.hfile.InclusiveCombinedBlockCache - Class in org.apache.hadoop.hbase.io.hfile
- InclusiveCombinedBlockCache(FirstLevelBlockCache, BlockCache) - Constructor for class org.apache.hadoop.hbase.io.hfile.InclusiveCombinedBlockCache
- org.apache.hadoop.hbase.filter.InclusiveStopFilter - Class in org.apache.hadoop.hbase.filter
-
A Filter that stops after the given row.
- InclusiveStopFilter(byte[]) - Constructor for class org.apache.hadoop.hbase.filter.InclusiveStopFilter
- incMemStoreSize(long, long, long, int) - Method in class org.apache.hadoop.hbase.regionserver.CompositeImmutableSegment
-
Updates the heap size counter of the segment by the given delta
- incMemStoreSize(long, long, long, int) - Method in interface org.apache.hadoop.hbase.regionserver.MemStoreSizing
-
Returns The new dataSize ONLY as a convenience
- incMemStoreSize(long, long, long, int) - Method in class org.apache.hadoop.hbase.regionserver.Segment
- incMemStoreSize(MemStoreSize) - Method in interface org.apache.hadoop.hbase.regionserver.MemStoreSizing
- incMethodTime(String, long) - Method in interface org.apache.hadoop.hbase.thrift.MetricsThriftServerSource
-
Add how long a method took
- incMethodTime(String, long) - Method in class org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceImpl
- incMethodTime(String, long) - Method in class org.apache.hadoop.hbase.thrift.ThriftMetrics
- incNumRowKeysInBatchGet(int) - Method in interface org.apache.hadoop.hbase.thrift.MetricsThriftServerSource
-
Add how many keys were in a batch get.
- incNumRowKeysInBatchGet(int) - Method in class org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceImpl
- incNumRowKeysInBatchGet(int) - Method in class org.apache.hadoop.hbase.thrift.ThriftMetrics
- incNumRowKeysInBatchMutate(int) - Method in interface org.apache.hadoop.hbase.thrift.MetricsThriftServerSource
-
Add how many keys were in a batch mutate.
- incNumRowKeysInBatchMutate(int) - Method in class org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceImpl
- incNumRowKeysInBatchMutate(int) - Method in class org.apache.hadoop.hbase.thrift.ThriftMetrics
- INCOMPATIBLE - Enum constant in enum class org.apache.hadoop.hbase.snapshot.ExportSnapshot.ChecksumComparison
- org.apache.hadoop.hbase.filter.IncompatibleFilterException - Exception in org.apache.hadoop.hbase.filter
-
Used to indicate a filter incompatibility
- IncompatibleFilterException() - Constructor for exception org.apache.hadoop.hbase.filter.IncompatibleFilterException
-
constructor
- IncompatibleFilterException(String) - Constructor for exception org.apache.hadoop.hbase.filter.IncompatibleFilterException
-
constructor
- INCONSISTENT_REGIONS - Static variable in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
- INCONSISTENT_REGIONS_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
- incrCacheDroppingExceptions(Object) - Method in class org.apache.hadoop.hbase.client.MetricsConnection
- incrDelayRunners() - Method in class org.apache.hadoop.hbase.client.MetricsConnection.RunnerStats
- incrDelayRunnersAndUpdateDelayInterval(long) - Method in class org.apache.hadoop.hbase.client.MetricsConnection
-
Increment the number of delay runner counts and update delay interval of delay runner.
- incReadRequests(long) - Method in interface org.apache.hadoop.hbase.master.MetricsMasterSource
-
Increment the number of read requests the cluster has seen.
- incReadRequests(long) - Method in class org.apache.hadoop.hbase.master.MetricsMasterSourceImpl
- increase(long) - Method in class org.apache.hadoop.hbase.regionserver.regionreplication.RegionReplicationBufferManager
-
Return whether we should just drop all the edits, if we have reached the hard limit of max pending size.
- increaseAboveHeapOccupancyLowWatermarkCounter() - Method in class org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManager
-
Increase the counter for heap occupancy percent above low watermark
- increaseAboveHeapOccupancyLowWatermarkCounter() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSource
-
Increase the counter for heap occupancy percent above low watermark
- increaseAboveHeapOccupancyLowWatermarkCounter() - Method in class org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSourceImpl
- increaseTunerDoNothingCounter() - Method in class org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManager
-
Increase the counter for tuner neither expanding memstore global size limit nor expanding blockcache max size.
- increaseTunerDoNothingCounter() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSource
-
Increase the counter for tuner neither expanding memstore global size limit nor expanding blockcache max size.
- increaseTunerDoNothingCounter() - Method in class org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSourceImpl
- org.apache.hadoop.hbase.regionserver.IncreasingToUpperBoundRegionSplitPolicy - Class in org.apache.hadoop.hbase.regionserver
-
Split size is the number of regions that are on this server that all are of the same table, cubed, times 2x the region flush size OR the maximum region split size, whichever is smaller.
- IncreasingToUpperBoundRegionSplitPolicy() - Constructor for class org.apache.hadoop.hbase.regionserver.IncreasingToUpperBoundRegionSplitPolicy
- increment() - Method in interface org.apache.hadoop.hbase.metrics.Counter
-
Increment
this
by 1. - increment(long) - Method in interface org.apache.hadoop.hbase.metrics.Counter
-
Increment
this
byn
. - increment(Increment) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
Increments one or more columns within a single row.
- increment(Increment) - Method in interface org.apache.hadoop.hbase.client.Table
-
Increments one or more columns within a single row.
- increment(Increment) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
- increment(Increment) - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Perform one or more increment operations on a row.
- increment(Increment, long, long) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
- increment(TIncrement) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
- increment(S) - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
-
Returns increment
- org.apache.hadoop.hbase.client.Increment - Class in org.apache.hadoop.hbase.client
-
Used to perform Increment operations on a single row.
- Increment(byte[]) - Constructor for class org.apache.hadoop.hbase.client.Increment
-
Create a Increment operation for the specified row.
- Increment(byte[], int, int) - Constructor for class org.apache.hadoop.hbase.client.Increment
-
Create a Increment operation for the specified row.
- Increment(byte[], long, NavigableMap<byte[], List<Cell>>) - Constructor for class org.apache.hadoop.hbase.client.Increment
-
Construct the Increment with user defined data.
- Increment(Increment) - Constructor for class org.apache.hadoop.hbase.client.Increment
-
Copy constructor
- INCREMENT - Enum constant in enum class org.apache.hadoop.hbase.coprocessor.RegionObserver.MutationType
- INCREMENT - Enum constant in enum class org.apache.hadoop.hbase.regionserver.Region.Operation
- INCREMENT_BLOCK_BYTES_SCANNED_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- INCREMENT_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- INCREMENTAL - Enum constant in enum class org.apache.hadoop.hbase.backup.BackupType
- INCREMENTAL_COPY - Enum constant in enum class org.apache.hadoop.hbase.backup.BackupInfo.BackupPhase
- incrementAppendCount(TableName) - Method in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
-
Increment the count of wal appends
- incrementAppendCount(TableName) - Method in class org.apache.hadoop.hbase.regionserver.wal.MetricsWALSourceImpl
- incrementAppendSize(TableName, long) - Method in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
-
Add the append size.
- incrementAppendSize(TableName, long) - Method in class org.apache.hadoop.hbase.regionserver.wal.MetricsWALSourceImpl
- incrementAppendTime(long) - Method in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
-
Add the time it took to append.
- incrementAppendTime(long) - Method in class org.apache.hadoop.hbase.regionserver.wal.MetricsWALSourceImpl
- incrementAuthFailedCount() - Method in interface org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSource
-
Increment the count of failed ops due to AUTHFAILED Exception.
- incrementAuthFailedCount() - Method in class org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSourceImpl
- incrementBadLineCount(int) - Method in class org.apache.hadoop.hbase.mapreduce.TextSortReducer
- incrementBadLineCount(int) - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
- incrementBadLineCount(int) - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterTextMapper
- incrementBlockBytesScanned(long) - Method in interface org.apache.hadoop.hbase.ipc.RpcCallContext
-
Increment the number of block bytes scanned by the current call.
- incrementBlockBytesScanned(long) - Method in class org.apache.hadoop.hbase.ipc.ServerCall
- incrementBytes(byte[], long) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Bytewise binary increment/deincrement of long contained in byte array on given amount.
- org.apache.hadoop.hbase.thrift.IncrementCoalescer - Class in org.apache.hadoop.hbase.thrift
-
This class will coalesce increments from a thift server if hbase.regionserver.thrift.coalesceIncrement is set to true.
- IncrementCoalescer(ThriftHBaseServiceHandler) - Constructor for class org.apache.hadoop.hbase.thrift.IncrementCoalescer
- org.apache.hadoop.hbase.thrift.IncrementCoalescerMBean - Interface in org.apache.hadoop.hbase.thrift
- incrementColumnValue(byte[], byte[], byte[], long) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
See
AsyncTable.incrementColumnValue(byte[], byte[], byte[], long, Durability)
- incrementColumnValue(byte[], byte[], byte[], long) - Method in interface org.apache.hadoop.hbase.client.Table
-
See
Table.incrementColumnValue(byte[], byte[], byte[], long, Durability)
- incrementColumnValue(byte[], byte[], byte[], long, Durability) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
Atomically increments a column value.
- incrementColumnValue(byte[], byte[], byte[], long, Durability) - Method in interface org.apache.hadoop.hbase.client.Table
-
Atomically increments a column value.
- incrementCompactionsQueuedCount() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
- incrementConnectionLossCount() - Method in interface org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSource
-
Increment the count of failed ops due to a CONNECTIONLOSS Exception.
- incrementConnectionLossCount() - Method in class org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSourceImpl
- incrementDataInconsistencyCount() - Method in interface org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSource
-
Increment the count of failed ops due to a DATAINCONSISTENCY Exception.
- incrementDataInconsistencyCount() - Method in class org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSourceImpl
- incrementEligible() - Method in class org.apache.hadoop.hbase.io.hfile.BloomFilterMetrics
-
Increment for cases where bloom filter could have been used but wasn't defined or loaded.
- incrementErrorLogRoll() - Method in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
- incrementErrorLogRoll() - Method in class org.apache.hadoop.hbase.regionserver.wal.MetricsWALSourceImpl
- incrementFailedAppendRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsREST
- incrementFailedAppendRequests(int) - Method in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
-
Increment the number failed append requests.
- incrementFailedAppendRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsRESTSourceImpl
- incrementFailedDeleteRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsREST
- incrementFailedDeleteRequests(int) - Method in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
-
Increment the number of failed Delete requests.
- incrementFailedDeleteRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsRESTSourceImpl
- incrementFailedGetRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsREST
- incrementFailedGetRequests(int) - Method in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
-
Increment the number of failed Get requests.
- incrementFailedGetRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsRESTSourceImpl
- incrementFailedIncrementRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsREST
- incrementFailedIncrementRequests(int) - Method in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
-
Increment the number failed increment requests.
- incrementFailedIncrementRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsRESTSourceImpl
- incrementFailedPutRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsREST
- incrementFailedPutRequests(int) - Method in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
-
Increment the number of failed Put Requests.
- incrementFailedPutRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsRESTSourceImpl
- incrementFailedScanRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsREST
- incrementFailedScanRequests(int) - Method in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
-
Increment the number failed scan requests.
- incrementFailedScanRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsRESTSourceImpl
- incrementFilteredReadRequests() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsUserSource.ClientMetrics
- incrementFlushesQueuedCount() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
- incrementFromThrift(TIncrement) - Static method in class org.apache.hadoop.hbase.thrift.ThriftUtilities
-
From a
TIncrement
create anIncrement
. - org.apache.hadoop.hbase.util.IncrementingEnvironmentEdge - Class in org.apache.hadoop.hbase.util
-
Uses an incrementing algorithm instead of the default.
- IncrementingEnvironmentEdge() - Constructor for class org.apache.hadoop.hbase.util.IncrementingEnvironmentEdge
-
Construct an incremental edge starting from currentTimeMillis
- IncrementingEnvironmentEdge(long) - Constructor for class org.apache.hadoop.hbase.util.IncrementingEnvironmentEdge
-
Construct an incremental edge with an initial amount
- incrementInvalidACLCount() - Method in interface org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSource
-
Increment the count of failed ops due to INVALIDACL Exception.
- incrementInvalidACLCount() - Method in class org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSourceImpl
- incrementIv(byte[]) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
- incrementIv(byte[], int) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
- incrementLogRollRequested() - Method in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
- incrementLogRollRequested() - Method in class org.apache.hadoop.hbase.regionserver.wal.MetricsWALSourceImpl
- incrementLowReplicationLogRoll() - Method in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
- incrementLowReplicationLogRoll() - Method in class org.apache.hadoop.hbase.regionserver.wal.MetricsWALSourceImpl
- incrementNoAuthCount() - Method in interface org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSource
-
Increment the count of failed ops due to NOAUTH Exception.
- incrementNoAuthCount() - Method in class org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSourceImpl
- incrementNumOfAppends() - Method in class org.apache.hadoop.hbase.regionserver.MiniBatchOperationInProgress
- incrementNumOfDeletes() - Method in class org.apache.hadoop.hbase.regionserver.MiniBatchOperationInProgress
- incrementNumOfIncrements() - Method in class org.apache.hadoop.hbase.regionserver.MiniBatchOperationInProgress
- incrementNumOfPuts() - Method in class org.apache.hadoop.hbase.regionserver.MiniBatchOperationInProgress
- incrementNumRegionSizeReportsSent(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
- incrementNumRegionSizeReportsSent(long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerQuotaSource
-
Updates the metric tracking how many region size reports were sent from this RegionServer to the Master.
- incrementNumRegionSizeReportsSent(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerQuotaSourceImpl
- incrementOperationCounter() - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManager
- incrementOperationCounter() - Method in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
-
TODO: Remove.
- incrementOperationCounter() - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManagerSourceImpl
- incrementOperationTimeoutCount() - Method in interface org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSource
-
Increment the count of failed ops due to an OPERATIONTIMEOUT Exception.
- incrementOperationTimeoutCount() - Method in class org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSourceImpl
- incrementQuotaObserverTime(long) - Method in class org.apache.hadoop.hbase.master.MetricsMaster
-
Sets the execution time of a period of the QuotaObserverChore.
- incrementReadRequest() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsUserSource.ClientMetrics
- incrementReadRequests(long) - Method in class org.apache.hadoop.hbase.master.MetricsMaster
- incrementRegionSize(RegionInfo, long) - Method in class org.apache.hadoop.hbase.quotas.NoOpRegionSizeStore
- incrementRegionSize(RegionInfo, long) - Method in interface org.apache.hadoop.hbase.quotas.RegionSizeStore
-
Atomically alter the size of a region.
- incrementRegionSize(RegionInfo, long) - Method in class org.apache.hadoop.hbase.quotas.RegionSizeStoreImpl
- incrementRegionSizeReportingChoreTime(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
- incrementRegionSizeReportingChoreTime(long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerQuotaSource
-
Updates the metric tracking how much time was spent sending region size reports to the Master by the RegionSizeReportingChore.
- incrementRegionSizeReportingChoreTime(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerQuotaSourceImpl
- incrementRequests(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.BloomFilterMetrics
-
Increment bloom request count, and negative result count if !passed
- incrementRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsREST
- incrementRequests(int) - Method in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
-
Increment the number of requests
- incrementRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsRESTSourceImpl
- incrementRequests(long) - Method in class org.apache.hadoop.hbase.master.MetricsMaster
- incrementResponseCellSize(long) - Method in interface org.apache.hadoop.hbase.ipc.RpcCallContext
-
Add on the given amount to the retained cell size.
- incrementResponseCellSize(long) - Method in class org.apache.hadoop.hbase.ipc.ServerCall
- incrementResponseExceptionSize(long) - Method in interface org.apache.hadoop.hbase.ipc.RpcCallContext
- incrementResponseExceptionSize(long) - Method in class org.apache.hadoop.hbase.ipc.ServerCall
- incrementRows(List<TIncrement>) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
- incrementRuntimeInconsistencyCount() - Method in interface org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSource
-
Increment the count of failed ops due to RUNTIMEINCONSISTENCY Exception.
- incrementRuntimeInconsistencyCount() - Method in class org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSourceImpl
- incrementServerOverloadedBackoffTime(long, TimeUnit) - Method in class org.apache.hadoop.hbase.client.MetricsConnection
-
Update the overloaded backoff time
- incrementSessionExpiredCount() - Method in interface org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSource
-
Increment the count of failed ops due to a SESSIONEXPIRED Exception.
- incrementSessionExpiredCount() - Method in class org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSourceImpl
- incrementSize(long) - Method in interface org.apache.hadoop.hbase.quotas.RegionSize
-
Atomically adds the provided
delta
to the region size. - incrementSize(long) - Method in class org.apache.hadoop.hbase.quotas.RegionSizeImpl
- incrementSizeLogRoll() - Method in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
- incrementSizeLogRoll() - Method in class org.apache.hadoop.hbase.regionserver.wal.MetricsWALSourceImpl
- incrementSlowAppendCount() - Method in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
-
Increment the number of appends that were slow
- incrementSlowAppendCount() - Method in class org.apache.hadoop.hbase.regionserver.wal.MetricsWALSourceImpl
- incrementSlowSyncLogRoll() - Method in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
- incrementSlowSyncLogRoll() - Method in class org.apache.hadoop.hbase.regionserver.wal.MetricsWALSourceImpl
- incrementSnapshotFetchTime(long) - Method in class org.apache.hadoop.hbase.master.MetricsMaster
-
Sets the execution time to fetch the mapping of snapshots to originating table.
- incrementSnapshotObserverChoreTime(long) - Method in interface org.apache.hadoop.hbase.master.MetricsMasterQuotaSource
-
Updates the metric tracking the amount of time taken by the
SnapshotQuotaObserverChore
which runs periodically. - incrementSnapshotObserverChoreTime(long) - Method in class org.apache.hadoop.hbase.master.MetricsMasterQuotaSourceImpl
- incrementSnapshotObserverSnapshotComputationTime(long) - Method in interface org.apache.hadoop.hbase.master.MetricsMasterQuotaSource
-
Updates the metric tracking the amount of time taken by the
SnapshotQuotaObserverChore
to compute the size of one snapshot, relative to the files referenced by the originating table. - incrementSnapshotObserverSnapshotComputationTime(long) - Method in class org.apache.hadoop.hbase.master.MetricsMasterQuotaSourceImpl
- incrementSnapshotObserverSnapshotFetchTime(long) - Method in interface org.apache.hadoop.hbase.master.MetricsMasterQuotaSource
-
Updates the metric tracking the amount of time taken by the
SnapshotQuotaObserverChore
to fetch all snapshots. - incrementSnapshotObserverSnapshotFetchTime(long) - Method in class org.apache.hadoop.hbase.master.MetricsMasterQuotaSourceImpl
- incrementSnapshotObserverTime(long) - Method in class org.apache.hadoop.hbase.master.MetricsMaster
-
Sets the execution time of a period of the
SnapshotQuotaObserverChore
. - incrementSnapshotSizeComputationTime(long) - Method in class org.apache.hadoop.hbase.master.MetricsMaster
-
Sets the execution time to compute the size of a single snapshot.
- incrementSpaceQuotaFileSystemScannerChoreTime(long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerQuotaSource
-
Updates the metric tracking how much time was spent scanning the filesystem to compute the size of each region hosted by this RegionServer.
- incrementSpaceQuotaFileSystemScannerChoreTime(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerQuotaSourceImpl
- incrementSpaceQuotaObserverChoreTime(long) - Method in interface org.apache.hadoop.hbase.master.MetricsMasterQuotaSource
-
Updates the metric tracking the amount of time taken by the
QuotaObserverChore
which runs periodically. - incrementSpaceQuotaObserverChoreTime(long) - Method in class org.apache.hadoop.hbase.master.MetricsMasterQuotaSourceImpl
- incrementSpaceQuotaRefresherChoreTime(long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerQuotaSource
-
Updates the metric tracking how much time was spent updating the RegionServer with the latest information on space quotas from the
hbase:quota
table. - incrementSpaceQuotaRefresherChoreTime(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerQuotaSourceImpl
- incrementSuccessfulLogRolls() - Method in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
-
Increment the number of successful log roll requests.
- incrementSuccessfulLogRolls() - Method in class org.apache.hadoop.hbase.regionserver.wal.MetricsWALSourceImpl
- incrementSucessfulAppendRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsREST
- incrementSucessfulAppendRequests(int) - Method in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
-
Increment the number of successful append requests.
- incrementSucessfulAppendRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsRESTSourceImpl
- incrementSucessfulDeleteRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsREST
- incrementSucessfulDeleteRequests(int) - Method in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
-
Increment the number of successful Delete requests.
- incrementSucessfulDeleteRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsRESTSourceImpl
- incrementSucessfulGetRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsREST
- incrementSucessfulGetRequests(int) - Method in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
-
Increment the number of successful Get requests.
- incrementSucessfulGetRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsRESTSourceImpl
- incrementSucessfulIncrementRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsREST
- incrementSucessfulIncrementRequests(int) - Method in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
-
Increment the number of successful increment requests.
- incrementSucessfulIncrementRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsRESTSourceImpl
- incrementSucessfulPutRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsREST
- incrementSucessfulPutRequests(int) - Method in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
-
Increment the number of successful Put requests.
- incrementSucessfulPutRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsRESTSourceImpl
- incrementSucessfulScanRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsREST
- incrementSucessfulScanRequests(int) - Method in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
-
Increment the number of successful scan requests.
- incrementSucessfulScanRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsRESTSourceImpl
- incrementSyncTime(long) - Method in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
-
Add the time it took to sync the wal.
- incrementSyncTime(long) - Method in class org.apache.hadoop.hbase.regionserver.wal.MetricsWALSourceImpl
- incrementSystemErrorCount() - Method in interface org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSource
-
Increment the count of failed ops due to a SYSTEMERROR Exception.
- incrementSystemErrorCount() - Method in class org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSourceImpl
- incrementTime(long) - Method in class org.apache.hadoop.hbase.util.IncrementingEnvironmentEdge
-
Increment the time by the given amount
- incrementTotalFailedZKCalls() - Method in interface org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSource
-
Record the total number of failed ZooKeeper API calls.
- incrementTotalFailedZKCalls() - Method in class org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSourceImpl
- incrementWriteRequest() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsUserSource.ClientMetrics
- incrementWriteRequests(long) - Method in class org.apache.hadoop.hbase.master.MetricsMaster
- incrementWrittenBytes(long) - Method in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
- incrementWrittenBytes(long) - Method in class org.apache.hadoop.hbase.regionserver.wal.MetricsWALSourceImpl
- incRequests(long) - Method in interface org.apache.hadoop.hbase.master.MetricsMasterSource
-
Increment the number of requests the cluster has seen.
- incRequests(long) - Method in class org.apache.hadoop.hbase.master.MetricsMasterSourceImpl
- incrFailedPuts(long) - Method in interface org.apache.hadoop.hbase.namequeues.MetricsWALEventTrackerSource
- incrFailedPuts(long) - Method in class org.apache.hadoop.hbase.namequeues.MetricsWALEventTrackerSourceImpl
- incrHedgedReadOps() - Method in class org.apache.hadoop.hbase.client.MetricsConnection
-
Increment the number of hedged read that have occurred.
- incrHedgedReadWin() - Method in class org.apache.hadoop.hbase.client.MetricsConnection
-
Increment the number of hedged read returned faster than the original read.
- incrMetaCacheHit() - Method in class org.apache.hadoop.hbase.client.MetricsConnection
-
Increment the number of meta cache hits.
- incrMetaCacheMiss() - Method in class org.apache.hadoop.hbase.client.MetricsConnection
-
Increment the number of meta cache misses.
- incrMetaCacheNumClearRegion() - Method in class org.apache.hadoop.hbase.client.MetricsConnection
-
Increment the number of meta cache drops requested for individual region.
- incrMetaCacheNumClearRegion(int) - Method in class org.apache.hadoop.hbase.client.MetricsConnection
-
Increment the number of meta cache drops requested for individual region.
- incrMetaCacheNumClearServer() - Method in class org.apache.hadoop.hbase.client.MetricsConnection
-
Increment the number of meta cache drops requested for entire RegionServer.
- incrNormalRunners() - Method in class org.apache.hadoop.hbase.client.MetricsConnection
-
Increment the number of normal runner counts.
- incrNormalRunners() - Method in class org.apache.hadoop.hbase.client.MetricsConnection.RunnerStats
- incrNsLookups() - Method in class org.apache.hadoop.hbase.client.MetricsConnection
- incrNsLookupsFailed() - Method in class org.apache.hadoop.hbase.client.MetricsConnection
- incrScannerLeaseExpired() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
- incrScannerLeaseExpired() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- incrScannerLeaseExpired() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
- incrSlowAppend() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
Increment the number of slow Appends that have happened.
- incrSlowAppend() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
- incrSlowDelete() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
Increment the number of slow Deletes that have happened.
- incrSlowDelete() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
- incrSlowFsRead() - Method in class org.apache.hadoop.hbase.io.MetricsIO
- incrSlowFsRead() - Method in interface org.apache.hadoop.hbase.io.MetricsIOSource
- incrSlowFsRead() - Method in class org.apache.hadoop.hbase.io.MetricsIOSourceImpl
- incrSlowGet() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
Increment the number of slow Gets that have happened.
- incrSlowGet() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
- incrSlowIncrement() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
Increment the number of slow Increments that have happened.
- incrSlowIncrement() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
- incrSlowPut() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
Increment the number of slow Puts that have happened.
- incrSlowPut() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
- incrSplitRequest() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
- incrSplitRequest() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
Increment number of a requested splits
- incrSplitRequest() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
- incrSplitRequest() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableSource
-
Increment number of a requested splits
- incrSplitRequest() - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableSourceImpl
- incrSplitRequest(String) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTable
- incrSplitSuccess() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
- incrSplitSuccess() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
Increment number of successful splits
- incrSplitSuccess() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
- incrSplitSuccess() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableSource
-
Increment number of successful splits
- incrSplitSuccess() - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableSourceImpl
- incrSplitSuccess(String) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTable
- incScannerCount() - Method in class org.apache.hadoop.hbase.regionserver.CompositeImmutableSegment
- incScannerCount() - Method in class org.apache.hadoop.hbase.regionserver.ImmutableMemStoreLAB
- incScannerCount() - Method in interface org.apache.hadoop.hbase.regionserver.MemStoreLAB
-
Called when opening a scanner on the data of this MemStoreLAB
- incScannerCount() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreLABImpl
-
Called when opening a scanner on the data of this MemStoreLAB
- incScannerCount() - Method in class org.apache.hadoop.hbase.regionserver.Segment
- incSlowCall(long) - Method in interface org.apache.hadoop.hbase.thrift.MetricsThriftServerSource
-
Increment how long a slow call took.
- incSlowCall(long) - Method in class org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceImpl
- incTaskCounters(Collection<byte[]>, ServerName) - Method in interface org.apache.hadoop.hbase.client.RequestController
-
Increment the counter if we build a valid task.
- incTimeInQueue(long) - Method in interface org.apache.hadoop.hbase.thrift.MetricsThriftServerSource
-
Add how long an operation was in the queue.
- incTimeInQueue(long) - Method in class org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceImpl
- incTimeInQueue(long) - Method in class org.apache.hadoop.hbase.thrift.ThriftMetrics
- incValue(long) - Method in class org.apache.hadoop.hbase.util.ManualEnvironmentEdge
- incWarnThresholdExceeded(int) - Method in interface org.apache.hadoop.hbase.metrics.JvmPauseMonitorSource
-
Increment the WARN level threshold exceeded count
- incWarnThresholdExceeded(int) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
- incWarnThresholdExceeded(int) - Method in class org.apache.hadoop.hbase.rest.MetricsRESTSourceImpl
- incWarnThresholdExceeded(int) - Method in class org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceImpl
- incWriteRequests(long) - Method in interface org.apache.hadoop.hbase.master.MetricsMasterSource
-
Increment the number of write requests the cluster has seen.
- incWriteRequests(long) - Method in class org.apache.hadoop.hbase.master.MetricsMasterSourceImpl
- INDEX - Enum constant in enum class org.apache.hadoop.hbase.io.hfile.BlockType.BlockCategory
- INDEX_BLOCK_ENCODING - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
- INDEX_BLOCK_ENCODING - Static variable in interface org.apache.hadoop.hbase.io.hfile.HFileIndexBlockEncoder
-
Type of encoding used for index blocks in HFile.
- INDEX_CHUNK - Enum constant in enum class org.apache.hadoop.hbase.regionserver.ChunkCreator.ChunkType
- INDEX_CHUNK_SIZE_PERCENTAGE_DEFAULT - Static variable in interface org.apache.hadoop.hbase.regionserver.MemStoreLAB
- INDEX_CHUNK_SIZE_PERCENTAGE_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MemStoreLAB
- INDEX_CHUNK_UNUSED_SPACE_PRECENTAGE - Static variable in class org.apache.hadoop.hbase.regionserver.CellChunkImmutableSegment
- INDEX_COLUMN - Static variable in class org.apache.hadoop.hbase.mapreduce.IndexBuilder
-
the column family containing the indexed row key
- INDEX_KEY_MAGIC - Static variable in class org.apache.hadoop.hbase.HConstants
-
Used as a magic return value while optimized index key feature enabled(HBASE-7845)
- INDEX_QUALIFIER - Static variable in class org.apache.hadoop.hbase.mapreduce.IndexBuilder
-
the qualifier containing the indexed row key
- INDEX_V1 - Enum constant in enum class org.apache.hadoop.hbase.io.hfile.BlockType
-
Block index magic string in version 1
- indexBlockEncoder - Variable in class org.apache.hadoop.hbase.io.hfile.HFileWriterImpl
- org.apache.hadoop.hbase.io.encoding.IndexBlockEncoding - Enum Class in org.apache.hadoop.hbase.io.encoding
-
Provide access to all index block encoding algorithms.
- org.apache.hadoop.hbase.mapreduce.IndexBuilder - Class in org.apache.hadoop.hbase.mapreduce
-
Example map/reduce job to construct index tables that can be used to quickly find a row based on the value of a column.
- IndexBuilder() - Constructor for class org.apache.hadoop.hbase.mapreduce.IndexBuilder
- org.apache.hadoop.hbase.mapreduce.IndexBuilder.Map - Class in org.apache.hadoop.hbase.mapreduce
-
Internal Mapper to be run by Hadoop.
- indexEntryOffHeapSize(boolean) - Method in class org.apache.hadoop.hbase.regionserver.CellChunkImmutableSegment
- indexEntryOffHeapSize(boolean) - Method in class org.apache.hadoop.hbase.regionserver.Segment
- indexEntryOnHeapSize(boolean) - Method in class org.apache.hadoop.hbase.regionserver.CellChunkImmutableSegment
- indexEntryOnHeapSize(boolean) - Method in class org.apache.hadoop.hbase.regionserver.Segment
- indexEntrySize() - Method in class org.apache.hadoop.hbase.regionserver.CellArrayImmutableSegment
- indexEntrySize() - Method in class org.apache.hadoop.hbase.regionserver.CellChunkImmutableSegment
- indexEntrySize() - Method in class org.apache.hadoop.hbase.regionserver.CompositeImmutableSegment
- indexEntrySize() - Method in class org.apache.hadoop.hbase.regionserver.CSLMImmutableSegment
- indexEntrySize() - Method in class org.apache.hadoop.hbase.regionserver.MutableSegment
- indexEntrySize() - Method in class org.apache.hadoop.hbase.regionserver.Segment
- indexOf(byte[], byte) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Returns the index of the first appearance of the value
target
inarray
. - indexOf(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Returns the start position of the first occurrence of the specified
target
withinarray
, or-1
if there is no such occurrence. - indexOf(Object) - Method in class org.apache.hadoop.hbase.util.SortedList
- org.apache.hadoop.hbase.io.hfile.IndexOnlyLruBlockCache - Class in org.apache.hadoop.hbase.io.hfile
-
An on heap block cache implementation extended LruBlockCache and only cache index block.
- IndexOnlyLruBlockCache(long, long, boolean, Configuration) - Constructor for class org.apache.hadoop.hbase.io.hfile.IndexOnlyLruBlockCache
- indexSize() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
- indexSize() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
- indexSize() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileReader
- indexWithinComponent - Variable in class org.apache.hadoop.hbase.util.ConcatenatedLists.Iterator
- org.apache.hadoop.hbase.IndividualBytesFieldCell - Class in org.apache.hadoop.hbase
- IndividualBytesFieldCell(byte[], byte[], byte[], long, KeyValue.Type, long, byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.IndividualBytesFieldCell
- IndividualBytesFieldCell(byte[], int, int, byte[], int, int, byte[], int, int, long, KeyValue.Type, long, byte[], int, int, byte[], int, int) - Constructor for class org.apache.hadoop.hbase.IndividualBytesFieldCell
- inetSocketAddress2String(InetSocketAddress) - Static method in class org.apache.hadoop.hbase.util.Addressing
-
Given an InetSocketAddress object returns a String represent of it.
- inflightWALClosures - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
Tracks the logs in the process of being closed.
- info(String, String) - Static method in class org.apache.hadoop.hbase.metrics.Interns
-
Get a metric info object
- INFO_THRESHOLD_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.metrics.JvmPauseMonitorSource
- INFO_THRESHOLD_COUNT_KEY - Static variable in interface org.apache.hadoop.hbase.metrics.JvmPauseMonitorSource
- INFO_THRESHOLD_KEY - Static variable in class org.apache.hadoop.hbase.util.JvmPauseMonitor
- INFOPORT_OPTION - Static variable in class org.apache.hadoop.hbase.thrift.Constants
- infoServer - Variable in class org.apache.hadoop.hbase.HBaseServerBase
- infoServer - Variable in class org.apache.hadoop.hbase.thrift.ThriftServer
- org.apache.hadoop.hbase.http.InfoServer - Class in org.apache.hadoop.hbase.http
-
Create a Jetty embedded server to answer http requests.
- InfoServer(String, String, int, boolean, Configuration) - Constructor for class org.apache.hadoop.hbase.http.InfoServer
-
Create a status server on the given port.
- INFRASTRUCTURE_SIZE - Static variable in interface org.apache.hadoop.hbase.Tag
- init() - Method in class org.apache.hadoop.hbase.backup.BackupDriver
- init() - Method in class org.apache.hadoop.hbase.backup.RestoreDriver
- init() - Method in interface org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination
-
Deprecated.Support method to init constants such as timeout.
- init() - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
- init() - Method in class org.apache.hadoop.hbase.hbtop.screen.AbstractScreenView
- init() - Method in class org.apache.hadoop.hbase.hbtop.screen.field.FieldScreenPresenter
- init() - Method in class org.apache.hadoop.hbase.hbtop.screen.field.FieldScreenView
- init() - Method in class org.apache.hadoop.hbase.hbtop.screen.help.HelpScreenPresenter
- init() - Method in class org.apache.hadoop.hbase.hbtop.screen.help.HelpScreenView
- init() - Method in class org.apache.hadoop.hbase.hbtop.screen.mode.ModeScreenPresenter
- init() - Method in class org.apache.hadoop.hbase.hbtop.screen.mode.ModeScreenView
- init() - Method in interface org.apache.hadoop.hbase.hbtop.screen.ScreenView
- init() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.FilterDisplayModeScreenPresenter
- init() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.FilterDisplayModeScreenView
- init() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.InputModeScreenPresenter
- init() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.InputModeScreenView
- init() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.MessageModeScreenPresenter
- init() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.MessageModeScreenView
- init() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.Paging
- init() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenPresenter
- init() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenView
- init() - Method in class org.apache.hadoop.hbase.http.jmx.JMXJsonServlet
-
Initialize this servlet.
- init() - Method in class org.apache.hadoop.hbase.io.crypto.aes.AESDecryptor
- init() - Method in class org.apache.hadoop.hbase.io.crypto.aes.AESEncryptor
- init() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
-
Build the scanner.
- init() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
-
Build the scanner.
- init() - Method in class org.apache.hadoop.hbase.mapreduce.DefaultVisibilityExpressionResolver
- init() - Method in interface org.apache.hadoop.hbase.mapreduce.VisibilityExpressionResolver
-
Giving a chance for the initialization.
- init() - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManagerSourceImpl
- init() - Method in class org.apache.hadoop.hbase.master.MetricsMasterFilesystemSourceImpl
- init() - Method in class org.apache.hadoop.hbase.master.MetricsMasterProcSourceImpl
- init() - Method in class org.apache.hadoop.hbase.master.MetricsMasterSourceImpl
- init() - Method in class org.apache.hadoop.hbase.master.MetricsSnapshotSourceImpl
- init() - Method in interface org.apache.hadoop.hbase.metrics.BaseSource
-
Clear out the metrics and re-prepare the source.
- init() - Method in class org.apache.hadoop.hbase.metrics.BaseSourceImpl
- init() - Method in class org.apache.hadoop.hbase.metrics.ExceptionTrackingSourceImpl
- init() - Method in class org.apache.hadoop.hbase.regionserver.Chunk
-
Actually claim the memory for this chunk.
- init() - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
Used to initialize the WAL.
- init() - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
- init() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeers
- init() - Method in class org.apache.hadoop.hbase.rest.MetricsRESTSourceImpl
- init() - Method in class org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceImpl
- init() - Method in interface org.apache.hadoop.hbase.wal.WAL
-
Used to initialize the WAL.
- init(byte[], TableName, long, long, List<UUID>, long, long, MultiVersionConcurrencyControl, NavigableMap<byte[], Integer>, Map<String, byte[]>) - Method in class org.apache.hadoop.hbase.wal.WALKeyImpl
- init(int) - Method in interface org.apache.hadoop.hbase.io.util.Dictionary
- init(int) - Method in class org.apache.hadoop.hbase.io.util.LRUDictionary
- init(String) - Method in interface org.apache.hadoop.hbase.io.crypto.KeyProvider
-
Initialize the key provider
- init(String) - Method in class org.apache.hadoop.hbase.io.crypto.KeyStoreKeyProvider
- init(String) - Method in class org.apache.hadoop.hbase.io.crypto.MockAesKeyProvider
- init(FilterConfig) - Method in class org.apache.hadoop.hbase.http.AdminAuthorizedFilter
- init(FilterConfig) - Method in class org.apache.hadoop.hbase.http.ClickjackingPreventionFilter
- init(FilterConfig) - Method in class org.apache.hadoop.hbase.http.HttpServer.QuotingInputFilter
- init(FilterConfig) - Method in class org.apache.hadoop.hbase.http.lib.StaticUserWebFilter.StaticUserFilter
- init(FilterConfig) - Method in class org.apache.hadoop.hbase.http.NoCacheFilter
- init(FilterConfig) - Method in class org.apache.hadoop.hbase.http.ProxyUserAuthenticationFilter
- init(FilterConfig) - Method in class org.apache.hadoop.hbase.http.SecurityHeadersFilter
- init(Configuration) - Method in class org.apache.hadoop.hbase.regionserver.throttle.StoreHotnessProtector
- init(Configuration, String) - Method in class org.apache.hadoop.hbase.wal.BoundedGroupingStrategy
- init(Configuration, String) - Method in class org.apache.hadoop.hbase.wal.NamespaceGroupingStrategy
- init(Configuration, String) - Method in interface org.apache.hadoop.hbase.wal.RegionGroupingProvider.RegionGroupingStrategy
- init(Configuration, ServiceAuthorizationManager) - Static method in class org.apache.hadoop.hbase.security.HBasePolicyProvider
- init(FileSystem, Path, Configuration, boolean, long, StreamSlowMonitor) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractProtobufLogWriter
- init(FileSystem, Path, Configuration, boolean, long, StreamSlowMonitor) - Method in interface org.apache.hadoop.hbase.wal.AsyncFSWALProvider.AsyncWriter
- init(FileSystem, Path, Configuration, boolean, long, StreamSlowMonitor) - Method in interface org.apache.hadoop.hbase.wal.FSHLogProvider.Writer
- init(FileSystem, Path, Configuration, long) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractProtobufWALReader
- init(FileSystem, Path, Configuration, long) - Method in interface org.apache.hadoop.hbase.wal.AbstractFSWALProvider.Initializer
-
A method to initialize a WAL reader.
- init(RpcScheduler.Context) - Method in class org.apache.hadoop.hbase.ipc.DelegatingRpcScheduler
- init(RpcScheduler.Context) - Method in class org.apache.hadoop.hbase.ipc.FifoRpcScheduler
- init(RpcScheduler.Context) - Method in class org.apache.hadoop.hbase.ipc.RpcScheduler
-
Does some quick initialization.
- init(RpcScheduler.Context) - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
- init(RegionServerServices, Configuration, SplitLogWorker.TaskExecutor, SplitLogWorker) - Method in interface org.apache.hadoop.hbase.coordination.SplitLogWorkerCoordination
-
Deprecated.Initialize internal values.
- init(RegionServerServices, Configuration, SplitLogWorker.TaskExecutor, SplitLogWorker) - Method in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination
-
Override setter from
SplitLogWorkerCoordination
- init(StoreScanner, AbstractMultiFileWriter.WriterFactory) - Method in class org.apache.hadoop.hbase.regionserver.AbstractMultiFileWriter
-
Initializes multi-writer before usage.
- init(ReplicationEndpoint.Context) - Method in class org.apache.hadoop.hbase.replication.BaseReplicationEndpoint
- init(ReplicationEndpoint.Context) - Method in class org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint
- init(ReplicationEndpoint.Context) - Method in interface org.apache.hadoop.hbase.replication.ReplicationEndpoint
-
Initialize the replication endpoint with the given context.
- init(WALFactory, Configuration, String, Abortable) - Method in class org.apache.hadoop.hbase.wal.AbstractWALProvider
- init(WALFactory, Configuration, String, Abortable) - Method in interface org.apache.hadoop.hbase.wal.WALProvider
-
Set up the provider to create wals.
- initCellFilters() - Method in class org.apache.hadoop.hbase.replication.ChainWALEntryFilter
- initClusterSchemaService() - Method in class org.apache.hadoop.hbase.master.HMaster
- initCredentials(JobConf) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
- initCredentials(Job) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
- initCredentialsForCluster(Job, Configuration) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Obtain an authentication token, for the specified cluster, on behalf of the current user and add it to the credentials for the given map reduce job.
- initCredentialsForCluster(Job, Configuration, URI) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Obtain an authentication token, for the specified cluster, on behalf of the current user and add it to the credentials for the given map reduce job.
- initCryptoCipher(RPCProtos.CryptoCipherMeta, Configuration) - Method in class org.apache.hadoop.hbase.security.HBaseSaslRpcClient
- initFilter(FilterContainer, Configuration) - Method in class org.apache.hadoop.hbase.http.FilterInitializer
-
Initialize a Filter to a FilterContainer.
- initFilter(FilterContainer, Configuration) - Method in class org.apache.hadoop.hbase.http.lib.AuthenticationFilterInitializer
-
Initializes hadoop-auth AuthenticationFilter.
- initFilter(FilterContainer, Configuration) - Method in class org.apache.hadoop.hbase.http.lib.StaticUserWebFilter
- initHFileInfo(ReaderContext) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
- INITIAL_MAX_TIMESTAMP - Static variable in class org.apache.hadoop.hbase.io.TimeRange
- INITIAL_MIN_TIMESTAMP - Static variable in class org.apache.hadoop.hbase.io.TimeRange
- INITIAL_REFRESH_DELAY_SECS - Static variable in class org.apache.hadoop.hbase.client.RpcConnectionRegistry
-
As end users could configure any nodes in a cluster as the initial bootstrap nodes, it is possible that different end users will configure the same machine which makes the machine over load.
- INITIAL_STRIPE_COUNT_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.StripeStoreConfig
-
The initial stripe count to create.
- initialChore() - Method in class org.apache.hadoop.hbase.ScheduledChore
-
Override to run a task before we start looping.
- initialClusterStatus - Variable in class org.apache.hadoop.hbase.HBaseCluster
-
Deprecated.the status of the cluster before we begin
- initialize() - Method in class org.apache.hadoop.hbase.favored.FavoredNodeAssignmentHelper
- initialize() - Method in interface org.apache.hadoop.hbase.master.LoadBalancer
-
Initialize the load balancer.
- initialize() - Method in class org.apache.hadoop.hbase.master.SnapshotOfRegionAssignmentFromMeta
-
Initialize the region assignment snapshot by scanning the hbase:meta table
- initialize() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Deprecated.use HRegion.createHRegion() or HRegion.openHRegion()
- initialize() - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupBasedLoadBalancer
- initialize(boolean) - Method in class org.apache.hadoop.hbase.regionserver.StoreEngine
- initialize(int, boolean, long, float, float, HeapMemoryManager, float) - Static method in class org.apache.hadoop.hbase.regionserver.ChunkCreator
-
Initializes the instance of ChunkCreator
- initialize(String[]) - Method in class org.apache.hadoop.hbase.util.LoadTestDataGeneratorWithMOB
- initialize(String[]) - Method in class org.apache.hadoop.hbase.util.LoadTestDataGeneratorWithTags
- initialize(Configuration) - Static method in class org.apache.hadoop.hbase.security.Superusers
-
Should be called only once to pre-load list of super users and super groups from Configuration.
- initialize(Connection) - Method in interface org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshotNotifier
-
Initializes the notifier.
- initialize(Connection) - Method in class org.apache.hadoop.hbase.quotas.TableSpaceQuotaSnapshotNotifier
- initialize(TableDescriptor, Configuration) - Method in class org.apache.hadoop.hbase.regionserver.DelimitedKeyPrefixRegionSplitRestriction
- initialize(TableDescriptor, Configuration) - Method in class org.apache.hadoop.hbase.regionserver.KeyPrefixRegionSplitRestriction
- initialize(TableDescriptor, Configuration) - Method in class org.apache.hadoop.hbase.regionserver.NoRegionSplitRestriction
- initialize(TableDescriptor, Configuration) - Method in class org.apache.hadoop.hbase.regionserver.RegionSplitRestriction
-
Initialize the RegionSplitRestriction instance
- initialize(TableSnapshotInputFormatImpl.InputSplit, Configuration) - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.RecordReader
- initialize(RegionServerServices, TableName, SpaceQuotaSnapshot) - Method in class org.apache.hadoop.hbase.quotas.policies.AbstractViolationPolicyEnforcement
- initialize(RegionServerServices, TableName, SpaceQuotaSnapshot) - Method in interface org.apache.hadoop.hbase.quotas.SpaceViolationPolicyEnforcement
-
Initializes this policy instance.
- initialize(Server, FileSystem, Path, Path, WALFactory) - Method in interface org.apache.hadoop.hbase.regionserver.ReplicationService
-
Initializes the replication service object.
- initialize(Server, FileSystem, Path, Path, WALFactory) - Method in class org.apache.hadoop.hbase.replication.ReplicationSinkServiceImpl
- initialize(JobConf) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormat
- initialize(JobConf) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
-
Handle subclass specific set up.
- initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReader
-
Initializes the reader.
- initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReaderImpl
-
Build the scanner.
- initialize(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
- initialize(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
Handle subclass specific set up.
- initialize(P) - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
-
This method should initialize any field(s) of the ColumnInterpreter with a parsing of the passed message bytes (used on the server side).
- initialized - Variable in class org.apache.hadoop.hbase.wal.AbstractWALProvider
- initializeFileSystem() - Method in class org.apache.hadoop.hbase.HBaseServerBase
- initializeFromMeta() - Method in class org.apache.hadoop.hbase.favored.FavoredNodesManager
- initializeMemStoreChunkCreator(HeapMemoryManager) - Method in class org.apache.hadoop.hbase.HBaseServerBase
- initializeQueues(int) - Method in class org.apache.hadoop.hbase.ipc.RpcExecutor
- org.apache.hadoop.hbase.regionserver.storefiletracker.InitializeStoreFileTrackerProcedure - Class in org.apache.hadoop.hbase.regionserver.storefiletracker
-
Procedure for setting StoreFileTracker information to table descriptor.
- InitializeStoreFileTrackerProcedure() - Constructor for class org.apache.hadoop.hbase.regionserver.storefiletracker.InitializeStoreFileTrackerProcedure
- InitializeStoreFileTrackerProcedure(MasterProcedureEnv, TableName) - Constructor for class org.apache.hadoop.hbase.regionserver.storefiletracker.InitializeStoreFileTrackerProcedure
- initializeTable(Connection, TableName) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
-
Allows subclasses to initialize the table information.
- initializeTable(Connection, TableName) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
Allows subclasses to initialize the table information.
- initialSize - Variable in class org.apache.hadoop.hbase.regionserver.IncreasingToUpperBoundRegionSplitPolicy
- initJob(String, String, Class<? extends TableMap>, JobConf) - Static method in class org.apache.hadoop.hbase.mapred.IdentityTableMap
-
Use this before submitting a TableMap job.
- initJob(String, String, String, Class<? extends TableMap>, JobConf) - Static method in class org.apache.hadoop.hbase.mapred.GroupingTableMap
-
Use this before submitting a TableMap job.
- initJob(String, Scan, Class<? extends TableMapper>, Job) - Static method in class org.apache.hadoop.hbase.mapreduce.IdentityTableMapper
-
Use this before submitting a TableMap job.
- initJob(String, Scan, String, Class<? extends TableMapper>, Job) - Static method in class org.apache.hadoop.hbase.mapreduce.GroupingTableMapper
-
Use this before submitting a TableMap job.
- initMetaAndIndex(HFile.Reader) - Method in class org.apache.hadoop.hbase.io.hfile.HFileInfo
-
should be called after initTrailerAndContext
- initMetrics(ThriftMetrics) - Method in class org.apache.hadoop.hbase.thrift.HBaseServiceHandler
- initMultiTableSnapshotMapperJob(Map<String, Collection<Scan>>, Class<? extends TableMap>, Class<?>, Class<?>, JobConf, boolean, Path) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
-
Sets up the job for reading from one or more multiple table snapshots, with one or more scans per snapshot.
- initMultiTableSnapshotMapperJob(Map<String, Collection<Scan>>, Class<? extends TableMapper>, Class<?>, Class<?>, Job, boolean, Path) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Sets up the job for reading from one or more table snapshots, with one or more scans per snapshot.
- initOutput(FileSystem, Path, boolean, int, short, long, StreamSlowMonitor, boolean) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractProtobufLogWriter
- initOutput(FileSystem, Path, boolean, int, short, long, StreamSlowMonitor, boolean) - Method in class org.apache.hadoop.hbase.regionserver.wal.AsyncProtobufLogWriter
- initOutput(FileSystem, Path, boolean, int, short, long, StreamSlowMonitor, boolean) - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogWriter
- initParameter(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.FlushRegionCallable
- initParameter(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.SnapshotRegionCallable
- initParameter(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.SnapshotVerifyCallable
- initParameter(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.SplitWALCallable
- initReader() - Method in class org.apache.hadoop.hbase.regionserver.HStoreFile
-
Initialize the reader used for pread.
- initReconfigurable(Configuration) - Method in class org.apache.hadoop.hbase.ipc.RpcServer
- initRootIndex(HFileBlock, int, CellComparator, int) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileIndexBlockEncoder.EncodedSeeker
- initRootIndex(HFileBlock, int, CellComparator, int) - Method in class org.apache.hadoop.hbase.io.hfile.NoOpIndexBlockEncoder.NoOpEncodedSeeker
- initSaslProperties(String) - Static method in class org.apache.hadoop.hbase.security.SaslUtil
-
Initialize SASL properties for a given RPC protection level.
- initScanMetrics(Scan) - Method in class org.apache.hadoop.hbase.client.AbstractClientScanner
-
Check and initialize if application wants to collect scan metrics
- initTableMapJob(String, String, Class<? extends TableMap>, Class<?>, Class<?>, JobConf) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
-
Use this before submitting a TableMap job.
- initTableMapJob(String, String, Class<? extends TableMap>, Class<?>, Class<?>, JobConf, boolean) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
- initTableMapJob(String, String, Class<? extends TableMap>, Class<?>, Class<?>, JobConf, boolean, Class<? extends InputFormat>) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
-
Use this before submitting a TableMap job.
- initTableMapperJob(byte[], Scan, Class<? extends TableMapper>, Class<?>, Class<?>, Job) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Use this before submitting a TableMap job.
- initTableMapperJob(byte[], Scan, Class<? extends TableMapper>, Class<?>, Class<?>, Job, boolean) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Use this before submitting a TableMap job.
- initTableMapperJob(byte[], Scan, Class<? extends TableMapper>, Class<?>, Class<?>, Job, boolean, Class<? extends InputFormat>) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Use this before submitting a TableMap job.
- initTableMapperJob(String, Scan, Class<? extends TableMapper>, Class<?>, Class<?>, Job) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Use this before submitting a TableMap job.
- initTableMapperJob(String, Scan, Class<? extends TableMapper>, Class<?>, Class<?>, Job, boolean) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Use this before submitting a TableMap job.
- initTableMapperJob(String, Scan, Class<? extends TableMapper>, Class<?>, Class<?>, Job, boolean, boolean, Class<? extends InputFormat>) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Use this before submitting a TableMap job.
- initTableMapperJob(String, Scan, Class<? extends TableMapper>, Class<?>, Class<?>, Job, boolean, Class<? extends InputFormat>) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Use this before submitting a TableMap job.
- initTableMapperJob(List<Scan>, Class<? extends TableMapper>, Class<?>, Class<?>, Job) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Use this before submitting a Multi TableMap job.
- initTableMapperJob(List<Scan>, Class<? extends TableMapper>, Class<?>, Class<?>, Job, boolean) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Use this before submitting a Multi TableMap job.
- initTableMapperJob(List<Scan>, Class<? extends TableMapper>, Class<?>, Class<?>, Job, boolean, boolean) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Use this before submitting a Multi TableMap job.
- initTableMapperJob(TableName, Scan, Class<? extends TableMapper>, Class<?>, Class<?>, Job) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Use this before submitting a TableMap job.
- initTableReduceJob(String, Class<? extends TableReduce>, JobConf) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
-
Use this before submitting a TableReduce job.
- initTableReduceJob(String, Class<? extends TableReduce>, JobConf, Class) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
-
Use this before submitting a TableReduce job.
- initTableReduceJob(String, Class<? extends TableReduce>, JobConf, Class, boolean) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
-
Use this before submitting a TableReduce job.
- initTableReducerJob(String, Class<? extends TableReducer>, Job) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Use this before submitting a TableReduce job.
- initTableReducerJob(String, Class<? extends TableReducer>, Job, Class) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Use this before submitting a TableReduce job.
- initTableReducerJob(String, Class<? extends TableReducer>, Job, Class, String) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Deprecated.Since 3.0.0, will be removed in 4.0.0. Use
TableMapReduceUtil.initTableReducerJob(String, Class, Job, Class, URI)
instead, where we use the connection uri to specify the target cluster. - initTableReducerJob(String, Class<? extends TableReducer>, Job, Class, String, boolean) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Deprecated.Since 3.0.0, will be removed in 4.0.0. Use
TableMapReduceUtil.initTableReducerJob(String, Class, Job, Class, URI, boolean)
instead, where we use the connection uri to specify the target cluster. - initTableReducerJob(String, Class<? extends TableReducer>, Job, Class, String, String, String) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Deprecated.Since 2.5.9, 2.6.1, 2.7.0, will be removed in 4.0.0. The
serverClass
andserverImpl
do not take effect any more, just useTableMapReduceUtil.initTableReducerJob(String, Class, Job, Class, String)
instead. - initTableReducerJob(String, Class<? extends TableReducer>, Job, Class, String, String, String, boolean) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Deprecated.Since 2.5.9, 2.6.1, 2.7.0, will be removed in 4.0.0. The
serverClass
andserverImpl
do not take effect any more, just useTableMapReduceUtil.initTableReducerJob(String, Class, Job, Class, String, boolean)
instead. - initTableReducerJob(String, Class<? extends TableReducer>, Job, Class, URI) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Use this before submitting a TableReduce job.
- initTableReducerJob(String, Class<? extends TableReducer>, Job, Class, URI, boolean) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Use this before submitting a TableReduce job.
- initTableSnapshotMapJob(String, String, Class<? extends TableMap>, Class<?>, Class<?>, JobConf, boolean, Path) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
-
Sets up the job for reading from a table snapshot.
- initTableSnapshotMapJob(String, String, Class<? extends TableMap>, Class<?>, Class<?>, JobConf, boolean, Path, RegionSplitter.SplitAlgorithm, int) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
-
Sets up the job for reading from a table snapshot.
- initTableSnapshotMapperJob(String, Scan, Class<? extends TableMapper>, Class<?>, Class<?>, Job, boolean, Path) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Sets up the job for reading from a table snapshot.
- initTableSnapshotMapperJob(String, Scan, Class<? extends TableMapper>, Class<?>, Class<?>, Job, boolean, Path, RegionSplitter.SplitAlgorithm, int) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Sets up the job for reading from a table snapshot.
- initTestTable() - Method in class org.apache.hadoop.hbase.util.LoadTestTool
- initTrailerAndContext(ReaderContext, Configuration) - Method in class org.apache.hadoop.hbase.io.hfile.HFileInfo
- initWAL(WAL) - Method in class org.apache.hadoop.hbase.wal.AbstractWALProvider
- initWALCellCodec(WALProtos.WALHeader, InputStream) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractProtobufWALReader
- injectEdge(EnvironmentEdge) - Static method in class org.apache.hadoop.hbase.util.EnvironmentEdgeManager
-
Injects the given edge such that it becomes the managed entity.
- org.apache.hadoop.hbase.io.hfile.InlineBlockWriter - Interface in org.apache.hadoop.hbase.io.hfile
-
A way to write "inline" blocks into an
HFile
. - INNER_STORE_COMPARATOR - Static variable in class org.apache.hadoop.hbase.InnerStoreCellComparator
- innerBuild() - Method in class org.apache.hadoop.hbase.ExtendedCellBuilderImpl
- org.apache.hadoop.hbase.InnerStoreCellComparator - Class in org.apache.hadoop.hbase
-
Compare two HBase cells inner store, skip compare family for better performance.
- InnerStoreCellComparator() - Constructor for class org.apache.hadoop.hbase.InnerStoreCellComparator
- INPUT_FILES_SEPARATOR_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.WALPlayer
- INPUT_TABLE - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
Job parameter that specifies the input table.
- org.apache.hadoop.hbase.hbtop.screen.top.InputModeScreenPresenter - Class in org.apache.hadoop.hbase.hbtop.screen.top
-
The presentation logic for the input mode.
- InputModeScreenPresenter(InputModeScreenView, String, List<String>, Function<String, ScreenView>) - Constructor for class org.apache.hadoop.hbase.hbtop.screen.top.InputModeScreenPresenter
- org.apache.hadoop.hbase.hbtop.screen.top.InputModeScreenView - Class in org.apache.hadoop.hbase.hbtop.screen.top
-
The input mode in the top screen.
- InputModeScreenView(Screen, Terminal, int, String, List<String>, Function<String, ScreenView>) - Constructor for class org.apache.hadoop.hbase.hbtop.screen.top.InputModeScreenView
- InputSplit() - Constructor for class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.InputSplit
- InputSplit(TableDescriptor, RegionInfo, List<String>, Scan, Path) - Constructor for class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.InputSplit
- inputStream - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractProtobufWALReader
- org.apache.hadoop.hbase.regionserver.InputStreamBlockDistribution - Class in org.apache.hadoop.hbase.regionserver
-
Computes the HDFSBlockDistribution for a file based on the underlying located blocks for an HdfsDataInputStream reading that file.
- InputStreamBlockDistribution(FSDataInputStream, StoreFileInfo) - Constructor for class org.apache.hadoop.hbase.regionserver.InputStreamBlockDistribution
-
This should only be called for the first FSDataInputStream of a StoreFile, in
HStoreFile.open()
. - inputStreamFromByteRange(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.types.PBType
-
Create a
CodedInputStream
from aPositionedByteRange
. - insert(Object) - Method in interface org.apache.hadoop.hbase.util.AvlUtil.AvlInsertOrReplace
- insert(Table, Put, long) - Method in class org.apache.hadoop.hbase.util.MultiThreadedWriter.HBaseWriterThread
- insert(Table, Put, long) - Method in class org.apache.hadoop.hbase.util.MultiThreadedWriterWithACL.HBaseWriterThreadWithACL
- insert(TNode, Object, AvlUtil.AvlKeyComparator<TNode>, AvlUtil.AvlInsertOrReplace<TNode>) - Static method in class org.apache.hadoop.hbase.util.AvlUtil.AvlTree
-
Insert a node into the tree.
- insert(TNode, TNode) - Static method in class org.apache.hadoop.hbase.util.AvlUtil.AvlTree
-
Insert a node into the tree.
- Insert - Enum constant in enum class org.apache.hadoop.hbase.hbtop.terminal.KeyPress.Type
- insertDataValue(long) - Method in class org.apache.hadoop.hbase.util.RollingStatCalculator
-
Inserts given data value to array of data values to be considered for statistics calculation
- insertNamespaceToMeta(Connection, NamespaceDescriptor) - Static method in class org.apache.hadoop.hbase.master.TableNamespaceManager
- insertNewFiles(Collection<HStoreFile>) - Method in interface org.apache.hadoop.hbase.regionserver.StoreFileManager
-
Adds new files, either for from MemStore flush or bulk insert, into the structure.
- insertNewFiles(Collection<HStoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
- install(Configuration, FileSystem, Stoppable, Thread) - Static method in class org.apache.hadoop.hbase.regionserver.ShutdownHook
-
Install a shutdown hook that calls stop on the passed Stoppable and then thread joins against the passed
threadToJoin
. - installed - Variable in class org.apache.hadoop.hbase.master.SplitLogManager.TaskBatch
-
Deprecated.
- INSTALLED - Enum constant in enum class org.apache.hadoop.hbase.Coprocessor.State
- installShutdownHook() - Method in class org.apache.hadoop.hbase.HBaseServerBase
-
In order to register ShutdownHook, this method is called when HMaster and HRegionServer are started.
- instance - Static variable in class org.apache.hadoop.hbase.zookeeper.EmptyWatcher
- instance() - Static method in class org.apache.hadoop.hbase.regionserver.SegmentFactory
- INSTANCE - Enum constant in enum class org.apache.hadoop.hbase.CompatibilitySingletonFactory.SingletonStorage
- INSTANCE - Enum constant in enum class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceFactoryImpl.FactoryStorage
- INSTANCE - Static variable in class org.apache.hadoop.hbase.io.hfile.NoOpDataBlockEncoder
- INSTANCE - Static variable in class org.apache.hadoop.hbase.io.hfile.NoOpIndexBlockEncoder
- INSTANCE - Static variable in class org.apache.hadoop.hbase.regionserver.throttle.NoLimitThroughputController
- instantiate(String, Constructor<T>, Object...) - Static method in class org.apache.hadoop.hbase.util.ReflectionUtils
- instantiate(Configuration) - Static method in class org.apache.hadoop.hbase.ipc.RpcControllerFactory
- instantiate(Configuration) - Static method in class org.apache.hadoop.hbase.security.UserProvider
-
Instantiate the
UserProvider
specified in the configuration and set the passed configuration viaUserProvider.setConf(Configuration)
- instantiateFilter(Configuration) - Static method in class org.apache.hadoop.hbase.mapreduce.Import
-
Create a
Filter
to apply to all incoming keys (KeyValues
) to optionally not include in the job output - instantiateHStore(ColumnFamilyDescriptor, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
- instantiateRegionScanner(Scan, List<KeyValueScanner>, long, long) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
- instantiateWithCustomCtor(String, Class<?>[], Object[]) - Static method in class org.apache.hadoop.hbase.util.ReflectionUtils
- inStates(TableState.State) - Method in class org.apache.hadoop.hbase.client.TableState
-
Check that table in given states
- inStates(TableState.State...) - Method in class org.apache.hadoop.hbase.client.TableState
-
Check that table in given states
- INTEGER - Enum constant in enum class org.apache.hadoop.hbase.hbtop.field.FieldValueType
- INTEGER - Static variable in class org.apache.hadoop.hbase.util.ClassSize
-
Overhead for an Integer
- INTEGRITY - Enum constant in enum class org.apache.hadoop.hbase.security.SaslUtil.QualityOfProtection
- INTERMEDIATE_INDEX - Enum constant in enum class org.apache.hadoop.hbase.io.hfile.BlockType
-
Intermediate-level version 2 index in the non-data block section
- internalAdd(ExtendedCell, boolean, MemStoreSizing, boolean) - Method in class org.apache.hadoop.hbase.regionserver.CompositeImmutableSegment
- internalAdd(ExtendedCell, boolean, MemStoreSizing, boolean) - Method in class org.apache.hadoop.hbase.regionserver.Segment
- internalDecodeKeyValues(DataInputStream, int, int, HFileBlockDefaultDecodingContext) - Method in class org.apache.hadoop.hbase.io.encoding.CopyKeyDataBlockEncoder
- internalDecodeKeyValues(DataInputStream, int, int, HFileBlockDefaultDecodingContext) - Method in class org.apache.hadoop.hbase.io.encoding.DiffKeyDeltaEncoder
- internalDecodeKeyValues(DataInputStream, int, int, HFileBlockDefaultDecodingContext) - Method in class org.apache.hadoop.hbase.io.encoding.FastDiffDeltaEncoder
- internalDecodeKeyValues(DataInputStream, int, int, HFileBlockDefaultDecodingContext) - Method in class org.apache.hadoop.hbase.io.encoding.PrefixKeyDeltaEncoder
- internalEncode(ExtendedCell, HFileBlockDefaultEncodingContext, DataOutputStream) - Method in class org.apache.hadoop.hbase.io.encoding.CopyKeyDataBlockEncoder
- internalEncode(ExtendedCell, HFileBlockDefaultEncodingContext, DataOutputStream) - Method in class org.apache.hadoop.hbase.io.encoding.DiffKeyDeltaEncoder
- internalEncode(ExtendedCell, HFileBlockDefaultEncodingContext, DataOutputStream) - Method in class org.apache.hadoop.hbase.io.encoding.FastDiffDeltaEncoder
- internalEncode(ExtendedCell, HFileBlockDefaultEncodingContext, DataOutputStream) - Method in class org.apache.hadoop.hbase.io.encoding.PrefixKeyDeltaEncoder
- internalFlushcache(WAL, long, Collection<HStore>, MonitoredTask, boolean, FlushLifeCycleTracker) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Flush the memstore.
- internalPrepareFlushCache(WAL, long, Collection<HStore>, MonitoredTask, boolean, FlushLifeCycleTracker) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
- org.apache.hadoop.hbase.regionserver.InternalScan - Class in org.apache.hadoop.hbase.regionserver
-
Special scanner, currently used for increment operations to allow additional server-side arguments for Scan operations.
- InternalScan(Get) - Constructor for class org.apache.hadoop.hbase.regionserver.InternalScan
- InternalScan(Scan) - Constructor for class org.apache.hadoop.hbase.regionserver.InternalScan
- org.apache.hadoop.hbase.regionserver.InternalScanner - Interface in org.apache.hadoop.hbase.regionserver
-
Internal scanners differ from client-side scanners in that they operate on HStoreKeys and byte[] instead of RowResults.
- internalStart(ZKWatcher) - Method in class org.apache.hadoop.hbase.HBaseRpcServicesBase
- internalStop() - Method in class org.apache.hadoop.hbase.HBaseRpcServicesBase
- org.apache.hadoop.hbase.metrics.Interns - Class in org.apache.hadoop.hbase.metrics
-
Helpers to create interned metrics info
- interruptedException(InterruptedException) - Method in class org.apache.hadoop.hbase.zookeeper.ZKWatcher
-
Handles InterruptedExceptions in client calls.
- interruptedExceptionNoThrow(InterruptedException, boolean) - Method in class org.apache.hadoop.hbase.zookeeper.ZKWatcher
-
Log the InterruptedException and interrupt current thread
- intFitsIn(int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Check how many bytes is required to store value.
- INVALID_HASH - Static variable in class org.apache.hadoop.hbase.util.Hash
-
Constant to denote invalid hash type.
- INVALID_REGION_NAME_FORMAT_MESSAGE - Static variable in interface org.apache.hadoop.hbase.client.RegionInfo
- INVALID_TABLE - Enum constant in enum class org.apache.hadoop.hbase.util.HbckErrorReporter.ERROR_CODE
-
Deprecated.
- invalidateConnection() - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Resets the connections so that the next time getConnection() is called, a new connection is created.
- org.apache.hadoop.hbase.InvalidFamilyOperationException - Exception in org.apache.hadoop.hbase
-
Thrown if a request is table schema modification is requested but made for an invalid family name.
- InvalidFamilyOperationException() - Constructor for exception org.apache.hadoop.hbase.InvalidFamilyOperationException
-
default constructor
- InvalidFamilyOperationException(Exception) - Constructor for exception org.apache.hadoop.hbase.InvalidFamilyOperationException
-
Constructor taking another exception.
- InvalidFamilyOperationException(String) - Constructor for exception org.apache.hadoop.hbase.InvalidFamilyOperationException
-
Constructor
- org.apache.hadoop.hbase.io.hfile.InvalidHFileException - Exception in org.apache.hadoop.hbase.io.hfile
-
Thrown when an invalid HFile format is detected
- InvalidHFileException() - Constructor for exception org.apache.hadoop.hbase.io.hfile.InvalidHFileException
-
constructor
- InvalidHFileException(String) - Constructor for exception org.apache.hadoop.hbase.io.hfile.InvalidHFileException
-
Constructor
- org.apache.hadoop.hbase.regionserver.InvalidMutationDurabilityException - Exception in org.apache.hadoop.hbase.regionserver
-
Thrown if Mutation's
Durability
is skip wal but table need replication. - InvalidMutationDurabilityException() - Constructor for exception org.apache.hadoop.hbase.regionserver.InvalidMutationDurabilityException
-
default constructor
- InvalidMutationDurabilityException(String) - Constructor for exception org.apache.hadoop.hbase.regionserver.InvalidMutationDurabilityException
- org.apache.hadoop.hbase.filter.InvalidRowFilterException - Exception in org.apache.hadoop.hbase.filter
-
Used to indicate an invalid RowFilter.
- InvalidRowFilterException() - Constructor for exception org.apache.hadoop.hbase.filter.InvalidRowFilterException
-
constructor
- InvalidRowFilterException(String) - Constructor for exception org.apache.hadoop.hbase.filter.InvalidRowFilterException
-
constructor
- invert(float[][]) - Method in class org.apache.hadoop.hbase.master.RegionPlacementMaintainer.RandomizedMatrix
-
Copy a given matrix into a new matrix, transforming each row index and each column index according to the inverse of the randomization scheme that was created at construction time.
- invertIndices(int[]) - Method in class org.apache.hadoop.hbase.master.RegionPlacementMaintainer.RandomizedMatrix
-
Given an array where each element
indices[i]
represents the randomized column index corresponding to randomized row indexi
, create a new array with the corresponding inverted indices. - invoke(Object, Method, Object[]) - Method in class org.apache.hadoop.hbase.thrift.HbaseHandlerMetricsProxy
- invokeMethod(Object, String, Object...) - Static method in class org.apache.hadoop.hbase.util.ReflectionUtils
-
Get and invoke the target method from the given object with given parameters
- IO_STOREFILE_BLOOM_BLOCK_SIZE - Static variable in class org.apache.hadoop.hbase.util.BloomFilterFactory
-
Target Bloom block size.
- IO_STOREFILE_BLOOM_ENABLED - Static variable in class org.apache.hadoop.hbase.util.BloomFilterFactory
-
Master switch to enable Bloom filters
- IO_STOREFILE_BLOOM_ERROR_RATE - Static variable in class org.apache.hadoop.hbase.util.BloomFilterFactory
-
Specifies the target error rate to use when selecting the number of keys per Bloom filter.
- IO_STOREFILE_BLOOM_MAX_FOLD - Static variable in class org.apache.hadoop.hbase.util.BloomFilterFactory
-
Maximum folding factor allowed.
- IO_STOREFILE_BLOOM_MAX_KEYS - Static variable in class org.apache.hadoop.hbase.util.BloomFilterFactory
-
For default (single-block) Bloom filters this specifies the maximum number of keys.
- IO_STOREFILE_DELETEFAMILY_BLOOM_ENABLED - Static variable in class org.apache.hadoop.hbase.util.BloomFilterFactory
-
Master switch to enable Delete Family Bloom filters
- IOErrorWithCause(Throwable) - Constructor for exception org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler.IOErrorWithCause
- org.apache.hadoop.hbase.util.IOExceptionConsumer<T> - Interface in org.apache.hadoop.hbase.util
- org.apache.hadoop.hbase.util.IOExceptionRunnable - Interface in org.apache.hadoop.hbase.util
- org.apache.hadoop.hbase.util.IOExceptionSupplier<V> - Interface in org.apache.hadoop.hbase.util
-
A supplier that throws IOException when get.
- ioOptimizedMode - Variable in class org.apache.hadoop.hbase.mob.DefaultMobStoreCompactor
- IPC_CLIENT_FALLBACK_TO_SIMPLE_AUTH_ALLOWED_DEFAULT - Static variable in interface org.apache.hadoop.hbase.ipc.RpcClient
- IPC_CLIENT_FALLBACK_TO_SIMPLE_AUTH_ALLOWED_KEY - Static variable in interface org.apache.hadoop.hbase.ipc.RpcClient
- IPC_SERVER_BULKLOAD_MAX_CALLQUEUE_LENGTH - Static variable in class org.apache.hadoop.hbase.ipc.RpcScheduler
- IPC_SERVER_MAX_CALLQUEUE_LENGTH - Static variable in class org.apache.hadoop.hbase.ipc.RpcScheduler
- IPC_SERVER_PRIORITY_MAX_CALLQUEUE_LENGTH - Static variable in class org.apache.hadoop.hbase.ipc.RpcScheduler
- IPC_SERVER_REPLICATION_MAX_CALLQUEUE_LENGTH - Static variable in class org.apache.hadoop.hbase.ipc.RpcScheduler
- org.apache.hadoop.hbase.client.trace.IpcClientSpanBuilder - Class in org.apache.hadoop.hbase.client.trace
-
Construct
Span
instances originating from the client side of an IPC. - IpcClientSpanBuilder() - Constructor for class org.apache.hadoop.hbase.client.trace.IpcClientSpanBuilder
- org.apache.hadoop.hbase.server.trace.IpcServerSpanBuilder - Class in org.apache.hadoop.hbase.server.trace
-
Construct
Span
instances originating from the server side of an IPC. - IpcServerSpanBuilder(RpcCall) - Constructor for class org.apache.hadoop.hbase.server.trace.IpcServerSpanBuilder
- IS_ACTIVE_MASTER_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
- IS_ACTIVE_MASTER_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
- IS_META - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
Used by rest interface to access this metadata attribute which denotes if it is a catalog table, either
hbase:meta
. - IS_MOB - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
- is32BitJVM() - Static method in class org.apache.hadoop.hbase.util.ClassSize
-
Determines if we are running in a 32-bit JVM.
- isAarch64() - Static method in class org.apache.hadoop.hbase.util.JVM
-
Check if the arch is aarch64;
- isAborted() - Method in interface org.apache.hadoop.hbase.Abortable
-
Check if the server or client was aborted.
- isAborted() - Method in class org.apache.hadoop.hbase.backup.BackupHFileCleaner
- isAborted() - Method in interface org.apache.hadoop.hbase.client.Admin
- isAborted() - Method in class org.apache.hadoop.hbase.client.HBaseHbck
- isAborted() - Method in class org.apache.hadoop.hbase.client.SharedConnection
- isAborted() - Method in class org.apache.hadoop.hbase.HBaseServerBase
- isAborted() - Method in class org.apache.hadoop.hbase.MockRegionServerServices
- isAborted() - Method in class org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint
- isAborted() - Method in class org.apache.hadoop.hbase.zookeeper.ZKWatcher
- isAboveHighWaterMark() - Method in class org.apache.hadoop.hbase.regionserver.RegionServerAccounting
-
Return the FlushType if we are above the memstore high water mark
- isAboveLowWaterMark() - Method in class org.apache.hadoop.hbase.regionserver.RegionServerAccounting
-
Return the FlushType if we're above the low watermark
- isAcceptableAddress(InetAddress) - Method in interface org.apache.hadoop.hbase.util.Addressing.AddressSelectionCondition
-
Condition on which to accept inet address
- isActiveMaster() - Method in class org.apache.hadoop.hbase.master.HMaster
-
Report whether this master is currently the active master or not.
- isActiveMaster() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Returns true if master is the active one
- isAdjacent(RegionInfo) - Method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Returns True if region is adjacent, either just before or just after this one.
- isAlive() - Method in class org.apache.hadoop.hbase.http.HttpServer
-
Test for the availability of the web server
- isAllTime() - Method in class org.apache.hadoop.hbase.io.TimeRange
-
Check if it is for all time
- isAlreadyCached(BlockCacheKey) - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCache
-
Checks whether the block for the passed key is already cached.
- isAlreadyCached(BlockCacheKey) - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
- isAlt() - Method in class org.apache.hadoop.hbase.hbtop.terminal.KeyPress
- isAlwaysFramed() - Method in enum class org.apache.hadoop.hbase.thrift.ImplType
- isAmd64() - Static method in class org.apache.hadoop.hbase.util.JVM
-
Check if the arch is amd64;
- isArchivedLogFile(Path) - Static method in class org.apache.hadoop.hbase.wal.AbstractFSWALProvider
- isAscendingOrder() - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.RowRange
- isAsyncPrefetch() - Method in class org.apache.hadoop.hbase.client.ImmutableScan
- isAsyncPrefetch() - Method in class org.apache.hadoop.hbase.client.Scan
- isAutoAdjust() - Method in enum class org.apache.hadoop.hbase.hbtop.field.Field
- isAvailable() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
- isAvailable() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Returns true if region is available (not closed and not closing)
- isAvailable(long) - Method in class org.apache.hadoop.hbase.quotas.RateLimiter
-
Are there enough available resources to allow execution?
- isBackReferencesDir(Path) - Static method in class org.apache.hadoop.hbase.io.FileLink
-
Checks if the specified directory path is a back reference links folder.
- isBadJvmVersion() - Static method in class org.apache.hadoop.hbase.util.JvmVersion
-
Return true if the current JVM version is known to be unstable with HBase.
- isBalancerEnabled() - Method in interface org.apache.hadoop.hbase.client.Admin
-
Query the current state of the balancer.
- isBalancerEnabled() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Query the current state of the balancer.
- isBalancerEnabled(RpcController, MasterProtos.IsBalancerEnabledRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- isBalancerOn() - Method in class org.apache.hadoop.hbase.master.HMaster
-
Queries the state of the
LoadBalancerStateStore
. - isBalancerOn() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Queries the state of the
LoadBalancerStateStore
. - isBalancerRan() - Method in class org.apache.hadoop.hbase.client.BalanceResponse
-
Returns true if the balancer ran, otherwise false.
- isBatchUpdate - Variable in class org.apache.hadoop.hbase.util.LoadTestTool
- isBlink() - Method in class org.apache.hadoop.hbase.hbtop.terminal.Attributes
- isBlink() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.Cell
- isBlobCopy(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Return true when the next encoded value in
src
uses BlobCopy encoding, false otherwise. - isBlobVar(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Return true when the next encoded value in
src
uses BlobVar encoding, false otherwise. - isBlockCacheEnabled() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Returns True if hfile DATA type blocks should be cached (You cannot disable caching of INDEX and BLOOM type blocks).
- isBloom() - Method in enum class org.apache.hadoop.hbase.io.hfile.BlockType
-
Returns whether this block category is bloom filter
- isBold() - Method in class org.apache.hadoop.hbase.hbtop.terminal.Attributes
- isBold() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.Cell
- isBroken() - Method in interface org.apache.hadoop.hbase.io.asyncfs.AsyncFSOutput
-
Whether the stream is broken.
- isBroken() - Method in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutput
- isBroken() - Method in class org.apache.hadoop.hbase.io.asyncfs.WrapperAsyncFSOutput
- isBulkLoaded() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileReader
- isBulkLoadResult() - Method in class org.apache.hadoop.hbase.regionserver.HStoreFile
- isBulkLoadResult() - Method in interface org.apache.hadoop.hbase.regionserver.StoreFile
-
Check if this storefile was created by bulk load.
- isBypass() - Method in interface org.apache.hadoop.hbase.quotas.QuotaLimiter
-
Returns true if the limiter is a noop
- isBypass() - Method in class org.apache.hadoop.hbase.quotas.QuotaState
-
Returns true if there is no quota information associated to this object
- isBypass() - Method in class org.apache.hadoop.hbase.quotas.RateLimiter
- isBypass() - Method in class org.apache.hadoop.hbase.quotas.TimeBasedLimiter
- isBypass() - Method in class org.apache.hadoop.hbase.quotas.UserQuotaState
-
Returns true if there is no quota information associated to this object
- isBypassable() - Method in class org.apache.hadoop.hbase.coprocessor.ObserverContextImpl
- isByteBufferReadable(FSDataInputStream) - Static method in class org.apache.hadoop.hbase.io.util.BlockIOUtils
- isCacheBloomsOnWrite() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Returns true if we should cache bloomfilter blocks on write
- isCacheDataOnWrite() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Returns true if we should cache data blocks on write
- isCacheEnabled() - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCache
-
API to check whether or not, the cache is enabled.
- isCacheEnabled() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
- isCacheIndexesOnWrite() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Returns true if we should cache index blocks on write
- isCacheMobBlocks(Scan) - Static method in class org.apache.hadoop.hbase.mob.MobUtils
-
Indicates whether the scan contains the information of caching blocks.
- isCanceled() - Method in class org.apache.hadoop.hbase.client.ClientCoprocessorRpcController
- isCanceled() - Method in class org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
- isCanceled() - Method in class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
- isCanceled() - Method in class org.apache.hadoop.hbase.ipc.ServerRpcController
- isCancelled() - Method in class org.apache.hadoop.hbase.JitterScheduledThreadPoolExecutorImpl.JitteredRunnableScheduledFuture
- isCatalogJanitorEnabled() - Method in interface org.apache.hadoop.hbase.client.Admin
-
Query on the catalog janitor state (Enabled/Disabled?).
- isCatalogJanitorEnabled() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Query on the catalog janitor state.
- isCatalogJanitorEnabled() - Method in class org.apache.hadoop.hbase.master.HMaster
- isCatalogJanitorEnabled(RpcController, MasterProtos.IsCatalogJanitorEnabledRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- isCheck() - Method in class org.apache.hadoop.hbase.backup.RestoreRequest
- isCheckExistenceOnly() - Method in class org.apache.hadoop.hbase.client.Get
- isCheckOnlyMemStore() - Method in class org.apache.hadoop.hbase.regionserver.InternalScan
-
Returns true if only the MemStore should be checked.
- isCheckOnlyStoreFiles() - Method in class org.apache.hadoop.hbase.regionserver.InternalScan
-
Returns true if only StoreFiles should be checked.
- isChoreScheduled(ScheduledChore) - Method in class org.apache.hadoop.hbase.ChoreService
-
Returns true when the chore is scheduled with the implementer of this interface
- isClassExempt(String, String[]) - Method in class org.apache.hadoop.hbase.util.CoprocessorClassLoader
-
Determines whether the given class should be exempt from being loaded by this ClassLoader.
- isClassLoaderLoaded() - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
- isCleanerChoreEnabled() - Method in interface org.apache.hadoop.hbase.client.Admin
-
Query on the cleaner chore state (Enabled/Disabled?).
- isCleanerChoreEnabled() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Query the current state of the cleaner chore.
- isCleanerChoreEnabled(RpcController, MasterProtos.IsCleanerChoreEnabledRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- isClientCellBlockSupported() - Method in interface org.apache.hadoop.hbase.ipc.RpcCallContext
-
If the client connected and specified a codec to use, then we will use this codec making cellblocks to return.
- isClientCellBlockSupported() - Method in class org.apache.hadoop.hbase.ipc.ServerCall
- isClientReadable(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZNodePaths
-
Returns whether the path is supposed to be readable by the client and DOES NOT contain sensitive information (world readable).
- isClientScannerAsyncPrefetch() - Method in class org.apache.hadoop.hbase.client.ConnectionConfiguration
- isClosed() - Method in interface org.apache.hadoop.hbase.client.AsyncConnection
-
Returns whether the connection is closed or not.
- isClosed() - Method in class org.apache.hadoop.hbase.client.AsyncConnectionImpl
- isClosed() - Method in interface org.apache.hadoop.hbase.client.Connection
-
Returns whether the connection is closed or not.
- isClosed() - Method in class org.apache.hadoop.hbase.client.SharedAsyncConnection
- isClosed() - Method in class org.apache.hadoop.hbase.client.SharedConnection
- isClosed() - Method in class org.apache.hadoop.hbase.master.RegionState
- isClosed() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
- isClosed() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Returns true if region is closed
- isClosed(AdminProtos.CloseRegionResponse) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ResponseConverter
-
Check if the region is closed from a CloseRegionResponse
- isClosedOrAbnormallyClosed() - Method in class org.apache.hadoop.hbase.master.RegionState
- isClosing() - Method in class org.apache.hadoop.hbase.master.RegionState
- isClosing() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
- isClosing() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Returns True if closing process has started
- isClosingOrClosedOnServer(ServerName) - Method in class org.apache.hadoop.hbase.master.RegionState
- isClusterRunning() - Method in interface org.apache.hadoop.hbase.testing.TestingHBaseCluster
-
Return whether the cluster is running.
- isClusterShutdown() - Method in class org.apache.hadoop.hbase.master.ServerManager
- isClusterUp() - Method in class org.apache.hadoop.hbase.HBaseServerBase
-
Returns True if the cluster is up.
- isClusterUp() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Returns True if cluster is up; false if cluster is not up (we are shutting down).
- isClusterUp() - Method in class org.apache.hadoop.hbase.MockRegionServerServices
- isClusterUp() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Returns True if the cluster is up.
- isClusterUp() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
Returns True if cluster is up; false if cluster is not up (we are shutting down).
- isClusterUp() - Method in class org.apache.hadoop.hbase.zookeeper.ClusterStatusTracker
-
Checks if cluster is up.
- isCodelQueueType(String) - Static method in class org.apache.hadoop.hbase.ipc.RpcExecutor
- isColumnSorted() - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler.ResultScannerWrapper
- isCombinedBlockCache() - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
- isCompactedAway() - Method in class org.apache.hadoop.hbase.regionserver.HStoreFile
- isCompaction - Variable in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
- isCompaction() - Method in class org.apache.hadoop.hbase.regionserver.CreateStoreFileWriterParams
- isCompaction(boolean) - Method in class org.apache.hadoop.hbase.regionserver.CreateStoreFileWriterParams
-
Whether we are creating a new file in a compaction
- isCompactionEnabled() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
Check if the compaction enable flag of the table is true.
- isCompactionMarker(Cell) - Static method in class org.apache.hadoop.hbase.wal.WALEdit
-
Returns true if the given cell is a serialized
WALProtos.CompactionDescriptor
- isCompactionNeeded() - Method in interface org.apache.hadoop.hbase.regionserver.HRegion.FlushResult
-
Returns True if the flush requested a compaction, else false
- isCompactionNeeded() - Method in class org.apache.hadoop.hbase.regionserver.HRegion.FlushResultImpl
-
Convenience method, the equivalent of checking if result is FLUSHED_COMPACTION_NEEDED.
- isCompactionsEnabled() - Method in class org.apache.hadoop.hbase.regionserver.CompactSplit
- isComplete() - Method in class org.apache.hadoop.hbase.security.AbstractHBaseSaslRpcClient
- isComplete() - Method in class org.apache.hadoop.hbase.security.HBaseSaslRpcServer
- isCompleted(Path) - Static method in class org.apache.hadoop.hbase.io.hfile.PrefetchExecutor
- isCompressedOrEncrypted() - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
-
Returns true when on-disk blocks are compressed, and/or encrypted; false otherwise.
- isCompressTags() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Returns Whether KV tags should be compressed along with DataBlockEncoding.
- isCompressTags() - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
- isConnectionException(Throwable) - Static method in class org.apache.hadoop.hbase.exceptions.ClientExceptionsUtil
-
Check if the exception is something that indicates that we cannot contact/communicate with the server.
- isCorrectEncoder(DataBlockEncoder, short) - Static method in enum class org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
-
Check if given encoder has this id.
- isCorrupted(Path, String, FileSystem) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog
-
Deprecated.
- isCreateRootDir() - Method in class org.apache.hadoop.hbase.StartMiniClusterOption
-
Deprecated.
- isCreateRootDir() - Method in class org.apache.hadoop.hbase.testing.TestingHBaseClusterOption
- isCreateWALDir() - Method in class org.apache.hadoop.hbase.StartMiniClusterOption
-
Deprecated.
- isCreateWALDir() - Method in class org.apache.hadoop.hbase.testing.TestingHBaseClusterOption
- isCtrl() - Method in class org.apache.hadoop.hbase.hbtop.terminal.KeyPress
- isCursor() - Method in class org.apache.hadoop.hbase.client.Result
-
Return true if this Result is a cursor to tell users where the server has scanned.
- isData() - Method in enum class org.apache.hadoop.hbase.io.hfile.BlockType
-
Returns whether this block type is encoded or unencoded data block
- isDead - Variable in class org.apache.hadoop.hbase.master.SplitLogManager.TaskBatch
-
Deprecated.
- isDeadlineQueueType(String) - Static method in class org.apache.hadoop.hbase.ipc.RpcExecutor
- isDeadServer(ServerName) - Method in class org.apache.hadoop.hbase.master.DeadServer
- isDecodeMemstoreTS() - Method in class org.apache.hadoop.hbase.io.hfile.HFileInfo
- isDefaultReplica(int) - Static method in class org.apache.hadoop.hbase.client.RegionReplicaUtil
-
Returns true if this replicaId corresponds to default replica for the region
- isDefaultReplica(RegionInfo) - Static method in class org.apache.hadoop.hbase.client.RegionReplicaUtil
-
Returns true if this region is a default replica for the region
- isDegenerate() - Method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Returns True if RegionInfo is degenerate...
- isDelete(byte) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
Return true if a delete type, a
KeyValue.Type.Delete
or a {KeyValue.Type#DeleteFamily} or aKeyValue.Type.DeleteColumn
KeyValue type. - isDelete(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Return true if a delete type, a
KeyValue.Type.Delete
or a {KeyValue.Type#DeleteFamily} or aKeyValue.Type.DeleteColumn
KeyValue type. - isDeleteColumnOrFamily(ExtendedCell) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
Returns True if this cell is a delete family or column type.
- isDeleteColumns(ExtendedCell) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
- isDeleteColumnVersion(ExtendedCell) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
- isDeleted(ExtendedCell) - Method in interface org.apache.hadoop.hbase.regionserver.querymatcher.DeleteTracker
-
Check if the specified cell buffer has been deleted by a previously seen delete.
- isDeleted(ExtendedCell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.NewVersionBehaviorTracker
-
This method is not idempotent, we will save some info to judge VERSION_MASKED.
- isDeleted(ExtendedCell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanDeleteTracker
-
Check if the specified Cell buffer has been deleted by a previously seen delete.
- isDeleteFamily(ExtendedCell) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
- isDeleteFamilyBloomEnabled(Configuration) - Static method in class org.apache.hadoop.hbase.util.BloomFilterFactory
-
Returns true if Delete Family Bloom filters are enabled in the given configuration
- isDeleteFamilyVersion(ExtendedCell) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
- isDeleteType(ExtendedCell) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
Returns True if this cell is a
KeyValue.Type.Delete
type. - isDirectBufferPooled() - Method in class org.apache.hadoop.hbase.ipc.HeapByteBufAllocator
- isDirectory(FileSystem, Boolean, Path) - Method in class org.apache.hadoop.hbase.util.AbstractFileStatusFilter
- isDisabled() - Method in class org.apache.hadoop.hbase.client.TableState
-
Returns True if table is disabled.
- isDisabledOrDisabling() - Method in class org.apache.hadoop.hbase.client.TableState
-
Returns True if
TableState.State.DISABLED
orTableState.State.DISABLED
- isDisabling() - Method in class org.apache.hadoop.hbase.client.TableState
-
Returns True if table is disabling.
- isDisplayByDefault() - Method in class org.apache.hadoop.hbase.hbtop.field.FieldInfo
- isDistributedCluster() - Method in class org.apache.hadoop.hbase.HBaseCluster
-
Deprecated.
- isDistributedFileSystem(FileSystem) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Returns True is
fs
is instance of DistributedFileSystem n - isDone() - Method in class org.apache.hadoop.hbase.JitterScheduledThreadPoolExecutorImpl.JitteredRunnableScheduledFuture
- isDone() - Method in class org.apache.hadoop.hbase.SplitLogTask
-
Deprecated.
- isDone() - Method in class org.apache.hadoop.hbase.util.MultiThreadedAction
- isDone(long) - Method in interface org.apache.hadoop.hbase.regionserver.querymatcher.ColumnTracker
-
Give the tracker a chance to declare it's done based on only the timestamp to allow an early out.
- isDone(long) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ExplicitColumnTracker
- isDone(long) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.NewVersionBehaviorTracker
- isDone(long) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanWildcardColumnTracker
- isDone(ServerName) - Method in class org.apache.hadoop.hbase.SplitLogTask
-
Deprecated.
- isDoNotRetry() - Method in exception org.apache.hadoop.hbase.ipc.RemoteWithExtrasException
-
Returns True if origin exception was a do not retry type.
- isDryRun() - Method in class org.apache.hadoop.hbase.client.BalanceRequest
-
Returns true if the balancer should run in dry run mode, otherwise false.
- isEmpty() - Method in class org.apache.hadoop.hbase.client.Mutation
-
Method to check if the familyMap is empty
- isEmpty() - Method in class org.apache.hadoop.hbase.client.Result
-
Check if the underlying Cell [] is empty or not
- isEmpty() - Method in interface org.apache.hadoop.hbase.client.RowAccess
-
Returns true if there are no elements.
- isEmpty() - Method in class org.apache.hadoop.hbase.filter.FilterListBase
- isEmpty() - Method in class org.apache.hadoop.hbase.hbtop.Record
- isEmpty() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileIndexBlockEncoder.EncodedSeeker
- isEmpty() - Method in class org.apache.hadoop.hbase.io.hfile.HFileInfo
- isEmpty() - Method in class org.apache.hadoop.hbase.io.hfile.NoOpIndexBlockEncoder.NoOpEncodedSeeker
- isEmpty() - Method in class org.apache.hadoop.hbase.ipc.AdaptiveLifoCoDelCallQueue
- isEmpty() - Method in class org.apache.hadoop.hbase.quotas.NoOpRegionSizeStore
- isEmpty() - Method in interface org.apache.hadoop.hbase.quotas.RegionSizeStore
-
Returns if the store is empty.
- isEmpty() - Method in class org.apache.hadoop.hbase.quotas.RegionSizeStoreImpl
- isEmpty() - Method in class org.apache.hadoop.hbase.RegionLocations
-
Returns whether there are non-null elements in the list
- isEmpty() - Method in class org.apache.hadoop.hbase.regionserver.CellFlatMap
- isEmpty() - Method in class org.apache.hadoop.hbase.regionserver.CellSet
- isEmpty() - Method in class org.apache.hadoop.hbase.regionserver.CompactionPipeline
- isEmpty() - Method in class org.apache.hadoop.hbase.regionserver.CompositeImmutableSegment
-
Returns whether the segment has any cells
- isEmpty() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreSize
- isEmpty() - Method in interface org.apache.hadoop.hbase.regionserver.querymatcher.DeleteTracker
-
Returns true if there are no current delete, false otherwise
- isEmpty() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.NewVersionBehaviorTracker
- isEmpty() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanDeleteTracker
- isEmpty() - Method in class org.apache.hadoop.hbase.regionserver.Segment
-
Returns whether the segment has any cells
- isEmpty() - Method in class org.apache.hadoop.hbase.rest.client.Cluster
-
Returns true if no locations have been added, false otherwise
- isEmpty() - Method in class org.apache.hadoop.hbase.thrift.CallQueue
- isEmpty() - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
- isEmpty() - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
- isEmpty() - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Returns true when this range is of zero length, false otherwise.
- isEmpty() - Method in class org.apache.hadoop.hbase.util.SortedList
- isEmpty() - Method in class org.apache.hadoop.hbase.wal.WALEdit
- isEmpty() - Method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.NodeAndData
-
Deprecated.
- isEmpty(ByteRange) - Static method in class org.apache.hadoop.hbase.util.AbstractByteRange
-
Returns true when
range
is of zero length, false otherwise. - isEmptyQuota(QuotaProtos.Quotas) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
- isEnable() - Method in class org.apache.hadoop.hbase.regionserver.throttle.StoreHotnessProtector
- isEnabled() - Method in class org.apache.hadoop.hbase.client.TableState
-
Returns True if table is
TableState.State.ENABLED
. - isEnabled() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerDescription
- isEnabled(Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.InputStreamBlockDistribution
-
True if we should derive StoreFile HDFSBlockDistribution from the underlying input stream
- isEnabled(Configuration) - Static method in interface org.apache.hadoop.hbase.regionserver.MemStoreLAB
- isEnabledOrEnabling() - Method in class org.apache.hadoop.hbase.client.TableState
-
Returns True if
TableState.State.ENABLED
orTableState.State.ENABLING
- isEnableTableLatenciesMetrics() - Method in class org.apache.hadoop.hbase.regionserver.metrics.MetricsTableRequests
- isEnabling() - Method in class org.apache.hadoop.hbase.client.TableState
-
Returns True if table is
TableState.State.ENABLING
. - isEnabTableQueryMeterMetrics() - Method in class org.apache.hadoop.hbase.regionserver.metrics.MetricsTableRequests
- isEncodedRegionName(byte[]) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Figure if the passed bytes represent an encoded region name or not.
- isEncodedValue(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Returns true when
src
appears to be positioned an encoded value, false otherwise. - isEncryptionEnabled(Configuration) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
-
Returns true if the column family encryption feature is enabled globally.
- isEndOfLine() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.Cell
- isEOF(InvalidProtocolBufferException) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Check whether this IPBE indicates EOF or not.
- isErr() - Method in class org.apache.hadoop.hbase.SplitLogTask
-
Deprecated.
- isErr(ServerName) - Method in class org.apache.hadoop.hbase.SplitLogTask
-
Deprecated.
- isError - Variable in class org.apache.hadoop.hbase.ipc.ServerCall
- isEvictBlocksOnClose() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Returns true if we should evict cached blocks from the blockcache on close
- isExceedSize(long) - Method in class org.apache.hadoop.hbase.regionserver.ConstantSizeRegionSplitPolicy
-
Returns true if region size exceed the sizeToCheck
- isExceedThrottleQuotaEnabled() - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
- isExceedThrottleQuotaEnabled() - Method in class org.apache.hadoop.hbase.quotas.QuotaCache
- isExceedThrottleQuotaEnabled(Connection) - Static method in class org.apache.hadoop.hbase.quotas.QuotaUtil
- isExclusive() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.Only one instance of hbck can modify HBase at a time.
- isExistingSource() - Method in class org.apache.hadoop.hbase.metrics.MetricRegistryInfo
-
Returns whether or not this MetricRegistry is for an existing BaseSource
- isExists(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.CommonFSUtils
-
Calls fs.exists().
- isExpiredSnapshot(long, long, long) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
Method to check whether TTL has expired for specified snapshot creation time and snapshot ttl.
- isFailedClose() - Method in class org.apache.hadoop.hbase.master.RegionState
- isFailedOpen() - Method in class org.apache.hadoop.hbase.master.RegionState
- isFailedServer(Address) - Method in class org.apache.hadoop.hbase.ipc.FailedServers
-
Check if the server should be considered as bad.
- isFallbackEnabled() - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupBasedLoadBalancer
- isFamilyEssential(byte[]) - Method in class org.apache.hadoop.hbase.filter.ColumnValueFilter
- isFamilyEssential(byte[]) - Method in class org.apache.hadoop.hbase.filter.Filter
-
Check that given column family is essential for filter to check row.
- isFamilyEssential(byte[]) - Method in class org.apache.hadoop.hbase.filter.FilterBase
-
By default, we require all scan's column families to be present.
- isFamilyEssential(byte[]) - Method in class org.apache.hadoop.hbase.filter.FilterList
- isFamilyEssential(byte[]) - Method in class org.apache.hadoop.hbase.filter.FilterListBase
- isFamilyEssential(byte[]) - Method in class org.apache.hadoop.hbase.filter.FilterWrapper
- isFamilyEssential(byte[]) - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
The only CF this filter needs is given column family.
- isFamilyEssential(byte[]) - Method in class org.apache.hadoop.hbase.filter.SkipFilter
- isFamilyEssential(byte[]) - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
- isFavoredNodeApplicable(RegionInfo) - Static method in class org.apache.hadoop.hbase.favored.FavoredNodesManager
-
Favored nodes are not applicable for system tables.
- isFifoQueueType(String) - Static method in class org.apache.hadoop.hbase.ipc.RpcExecutor
- isFile(FileSystem, Boolean, Path) - Method in class org.apache.hadoop.hbase.util.AbstractFileStatusFilter
- isFileDeletable(FileStatus) - Method in class org.apache.hadoop.hbase.backup.BackupHFileCleaner
- isFileDeletable(FileStatus) - Method in class org.apache.hadoop.hbase.mob.ManualMobMaintHFileCleaner
- isFileInfoLoaded() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
- isFileScanner() - Method in interface org.apache.hadoop.hbase.regionserver.KeyValueScanner
-
Returns true if this is a file scanner.
- isFileScanner() - Method in class org.apache.hadoop.hbase.regionserver.NonLazyKeyValueScanner
- isFileScanner() - Method in class org.apache.hadoop.hbase.regionserver.SegmentScanner
-
Returns true if this is a file scanner.
- isFileScanner() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
- isFilterDone() - Method in interface org.apache.hadoop.hbase.regionserver.RegionScanner
- isFinished() - Method in interface org.apache.hadoop.hbase.master.SnapshotSentinel
-
Check to see if the snapshot is finished, where finished may be success or failure.
- isFirst() - Method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Returns True if this is first Region in Table
- isFixedFloat32(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Return true when the next encoded value in
src
uses fixed-width Float32 encoding, false otherwise. - isFixedFloat64(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Return true when the next encoded value in
src
uses fixed-width Float64 encoding, false otherwise. - isFixedInt16(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Return true when the next encoded value in
src
uses fixed-width Int16 encoding, false otherwise. - isFixedInt32(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Return true when the next encoded value in
src
uses fixed-width Int32 encoding, false otherwise. - isFixedInt64(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Return true when the next encoded value in
src
uses fixed-width Int64 encoding, false otherwise. - isFixedInt8(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Return true when the next encoded value in
src
uses fixed-width Int8 encoding, false otherwise. - isFlushSucceeded() - Method in interface org.apache.hadoop.hbase.regionserver.HRegion.FlushResult
-
Returns true if the memstores were flushed, else false
- isFlushSucceeded() - Method in class org.apache.hadoop.hbase.regionserver.HRegion.FlushResultImpl
-
Convenience method, the equivalent of checking if result is FLUSHED_NO_COMPACTION_NEEDED or FLUSHED_NO_COMPACTION_NEEDED.
- isFull() - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil.CachedBlocksByFile
- isFullServerName(String) - Static method in class org.apache.hadoop.hbase.ServerName
-
Returns true if the String follows the pattern of
ServerName.toString()
, false otherwise. - isGeneralBloomEnabled(Configuration) - Static method in class org.apache.hadoop.hbase.util.BloomFilterFactory
-
Returns true if general Bloom (Row or RowCol) filters are enabled in the given configuration
- isGet() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.NormalUserScanQueryMatcher
- isGet() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.RawScanQueryMatcher
- isGet() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.UserScanQueryMatcher
- isGetScan() - Method in class org.apache.hadoop.hbase.client.ImmutableScan
- isGetScan() - Method in class org.apache.hadoop.hbase.client.Scan
- isGroupPrincipal(String) - Static method in class org.apache.hadoop.hbase.AuthUtil
-
Deprecated.Returns whether or not the given name should be interpreted as a group principal.
- isGuaranteedClientSideOnly() - Method in exception org.apache.hadoop.hbase.exceptions.PreemptiveFastFailException
-
Deprecated.Returns true if we know no mutation made it to the server, false otherwise.
- isGZIPOutputStreamFinishBroken() - Static method in class org.apache.hadoop.hbase.util.JVM
-
Check if the finish() method of GZIPOutputStream is broken
- isHadoopSecurityEnabled() - Method in class org.apache.hadoop.hbase.security.UserProvider
-
Return whether or not Kerberos authentication is configured for Hadoop.
- isHashCached() - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
- isHBaseClusterRunning() - Method in interface org.apache.hadoop.hbase.testing.TestingHBaseCluster
-
Return whether the hbase cluster is running.
- isHBaseSecurityEnabled() - Method in class org.apache.hadoop.hbase.security.UserProvider
-
Returns true if security is enabled, false otherwise
- isHBaseSecurityEnabled(Configuration) - Static method in class org.apache.hadoop.hbase.security.User
-
Returns whether or not secure authentication is enabled for HBase.
- isHDFS(Configuration) - Static method in class org.apache.hadoop.hbase.util.CommonFSUtils
-
Return true if this is a filesystem whose scheme is 'hdfs'.
- isHdfsRegioninfoPresent() - Method in class org.apache.hadoop.hbase.util.HbckRegionInfo
- isHeapUsageBelowThreshold() - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
Checks if the current heap usage is below the threshold configured by "hbase.rs.prefetchheapusage" (0.8 by default).
- isHeldByCurrentThread(long) - Method in class org.apache.hadoop.hbase.util.IdLock
-
Test whether the given id is already locked by the current thread.
- isHFile() - Method in class org.apache.hadoop.hbase.regionserver.HStoreFile
- isHFile() - Method in interface org.apache.hadoop.hbase.regionserver.StoreFile
-
Returns True if this is HFile.
- isHFile(String) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
- isHFile(Path) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
- isHFileFormat(FileSystem, FileStatus) - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
-
Returns true if the specified file has a valid HFile Trailer.
- isHFileFormat(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
-
Returns true if the specified file has a valid HFile Trailer.
- isHFileLink(String) - Static method in class org.apache.hadoop.hbase.io.HFileLink
- isHFileLink(Path) - Static method in class org.apache.hadoop.hbase.io.HFileLink
- isHistorical() - Method in class org.apache.hadoop.hbase.regionserver.HStoreFile
- isHttpEnabled() - Method in enum class org.apache.hadoop.hbase.http.HttpConfig.Policy
- isHttpsEnabled() - Method in enum class org.apache.hadoop.hbase.http.HttpConfig.Policy
- isIgnoreRegionsInTransition() - Method in class org.apache.hadoop.hbase.client.BalanceRequest
-
Returns true if the balancer should execute even if regions are in transition, otherwise false.
- isIncludesMvcc() - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
- isIncludesTags() - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
- isIndex() - Method in enum class org.apache.hadoop.hbase.io.hfile.BlockType
-
Returns whether this block category is index
- isInitialChoreComplete() - Method in class org.apache.hadoop.hbase.ScheduledChore
- isInitialized() - Method in class org.apache.hadoop.hbase.master.HMaster
-
Report whether this master has completed with its initialization and is ready.
- isInitialized() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Returns true if master is initialized
- isInitialized() - Method in class org.apache.hadoop.hbase.namespace.NamespaceAuditor
-
Checks if namespace auditor is initialized.
- isInitOnly - Variable in class org.apache.hadoop.hbase.util.LoadTestTool
- isInMaintenanceMode() - Method in class org.apache.hadoop.hbase.master.HMaster
-
Report whether this master is in maintenance mode.
- isInMaintenanceMode() - Method in interface org.apache.hadoop.hbase.master.MasterServices
- isInMaintenanceMode() - Method in class org.apache.hadoop.hbase.zookeeper.MasterMaintenanceModeTracker
- isInMemory() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Returns True if we are to favor keeping all values for this column family in the HRegionServer cache.
- isInMemory() - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
Returns true if blocks in this file should be flagged as in-memory
- isInReturnCodes(Filter.ReturnCode, Filter.ReturnCode...) - Static method in class org.apache.hadoop.hbase.filter.FilterListBase
- isInRpcCallContext() - Static method in class org.apache.hadoop.hbase.ipc.RpcServer
- isInStates(TableState.State...) - Method in class org.apache.hadoop.hbase.client.TableState
-
Static version of state checker
- isInstrumentationAccessAllowed(ServletContext, HttpServletRequest, HttpServletResponse) - Static method in class org.apache.hadoop.hbase.http.HttpServer
-
Checks the user has privileges to access to instrumentation servlets.
- isInterrupt(Throwable) - Static method in class org.apache.hadoop.hbase.util.ExceptionUtil
-
Returns true if the throwable comes an interruption, false otherwise.
- isInViolation() - Method in class org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot.SpaceQuotaStatus
-
Returns
true
if the quota is being violated,false
otherwise. - isInViolation() - Method in interface org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshotView.SpaceQuotaStatusView
-
Returns
true
if the quota is being violated,false
otherwise. - isIterationFinished() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenPresenter
- isKilledRS(ServerName) - Method in class org.apache.hadoop.hbase.HBaseCluster
-
Deprecated.Keeping track of killed servers and being able to check if a particular server was killed makes it possible to do fault tolerance testing for dead servers in a deterministic way.
- isKilledRS(ServerName) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.
- isLargeLog() - Method in class org.apache.hadoop.hbase.namequeues.RpcLogDetails
- isLast() - Method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Returns True if this is last Region in Table
- isLatestTimestamp() - Method in class org.apache.hadoop.hbase.KeyValue
-
Returns True if this KeyValue has a LATEST_TIMESTAMP timestamp.
- isLeaseRecoverable(FileSystem) - Static method in class org.apache.hadoop.hbase.util.RecoverLeaseFSUtils
- isLeftJustify() - Method in enum class org.apache.hadoop.hbase.hbtop.field.Field
- isLegalColumnFamilyName(byte[]) - Static method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
Check if the column family name is legal.
- isLegalFullyQualifiedTableName(byte[]) - Static method in class org.apache.hadoop.hbase.TableName
-
Check passed byte array, "tableName", is legal user-space table name.
- isLegalNamespaceName(byte[]) - Static method in class org.apache.hadoop.hbase.TableName
- isLegalNamespaceName(byte[], int, int) - Static method in class org.apache.hadoop.hbase.TableName
-
Valid namespace characters are alphabetic characters, numbers, and underscores.
- isLegalTableQualifierName(byte[]) - Static method in class org.apache.hadoop.hbase.TableName
- isLegalTableQualifierName(byte[], boolean) - Static method in class org.apache.hadoop.hbase.TableName
- isLegalTableQualifierName(byte[], int, int) - Static method in class org.apache.hadoop.hbase.TableName
-
Qualifier names can only contain 'word' characters
[\p{IsAlphabetic}\p{Digit}]
or '_', '.' or '-'. - isLegalTableQualifierName(byte[], int, int, boolean) - Static method in class org.apache.hadoop.hbase.TableName
- isLink() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
Returns True if the store file is a link
- isLinked(TNode) - Static method in class org.apache.hadoop.hbase.util.AvlUtil.AvlIterableList
-
Return true if the node is linked to a list, false otherwise
- isLinux() - Static method in class org.apache.hadoop.hbase.util.JVM
-
Check if the OS is linux.
- isLoadingCfsOnDemandDefault() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
- isLocal(Configuration) - Static method in class org.apache.hadoop.hbase.LocalHBaseCluster
- isLocalAddress(InetAddress) - Static method in class org.apache.hadoop.hbase.util.Addressing
-
Given an InetAddress, checks to see if the address is a local address, by comparing the address with all the interfaces on the node.
- isLocked() - Method in class org.apache.hadoop.hbase.client.locking.EntityLock
- isLoginFromKeytab() - Method in class org.apache.hadoop.hbase.security.User
-
Returns true if user credentials are obtained from keytab.
- isLogRollRequested() - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
- isMajorCompactionResult() - Method in class org.apache.hadoop.hbase.regionserver.HStoreFile
- isMajorCompactionResult() - Method in interface org.apache.hadoop.hbase.regionserver.StoreFile
-
Returns True if this file was made by a major compaction.
- isMasterInMaintenanceMode() - Method in interface org.apache.hadoop.hbase.client.Admin
-
Check whether Master is in maintenance mode.
- isMasterInMaintenanceMode() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Check whether master is in maintenance mode
- isMasterInMaintenanceMode(RpcController, MasterProtos.IsInMaintenanceModeRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- isMasterRunning(RpcController, MasterProtos.IsMasterRunningRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- isMatchingTail(Path, String) - Static method in class org.apache.hadoop.hbase.util.CommonFSUtils
-
Compare path component of the Path URI; e.g.
- isMatchingTail(Path, Path) - Static method in class org.apache.hadoop.hbase.util.CommonFSUtils
-
Compare path component of the Path URI; e.g.
- isMatchingTail(Path, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Compare path component of the Path URI; e.g.
- isMaxColumnInclusive() - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
-
Returns if max column range is inclusive.
- isMergeable() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
- isMergeable() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Returns true if region is mergeable
- isMerged() - Method in class org.apache.hadoop.hbase.master.RegionState
- isMerged() - Method in class org.apache.hadoop.hbase.util.HbckRegionInfo
- isMergeEnabled() - Method in interface org.apache.hadoop.hbase.client.Admin
-
Query the current state of the merge switch.
- isMergeEnabled() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Query the current state of the Merge switch.
- isMergeEnabled() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
Check if the merge enable flag of the table is true.
- isMergeQualifierPrefix(Cell) - Static method in class org.apache.hadoop.hbase.CatalogFamilyFormat
-
Returns True if the column in
cell
matches the regex 'info:merge.*'. - isMerging() - Method in class org.apache.hadoop.hbase.master.RegionState
- isMergingNew() - Method in class org.apache.hadoop.hbase.master.RegionState
- isMergingNewOnServer(ServerName) - Method in class org.apache.hadoop.hbase.master.RegionState
- isMergingNewOrOfflineOnServer(ServerName) - Method in class org.apache.hadoop.hbase.master.RegionState
- isMergingNewOrOpenedOnServer(ServerName) - Method in class org.apache.hadoop.hbase.master.RegionState
- isMergingOnServer(ServerName) - Method in class org.apache.hadoop.hbase.master.RegionState
- isMetaBlock(BlockType) - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCache
-
Check if block type is meta or index block
- isMetaClearingException(Throwable) - Static method in class org.apache.hadoop.hbase.exceptions.ClientExceptionsUtil
- isMetaEdit() - Method in class org.apache.hadoop.hbase.wal.WALEdit
- isMetaEditFamily(byte[]) - Static method in class org.apache.hadoop.hbase.wal.WALEdit
-
Deprecated.Since 2.3.0. Do not expose. Make protected.
- isMetaEditFamily(Cell) - Static method in class org.apache.hadoop.hbase.wal.WALEdit
-
Replaying WALs can read Cell-at-a-time so need this method in those cases.
- isMetaFile(String) - Static method in class org.apache.hadoop.hbase.wal.AbstractFSWALProvider
-
Returns True if String ends in
AbstractFSWALProvider.META_WAL_PROVIDER_ID
- isMetaFile(Path) - Static method in class org.apache.hadoop.hbase.wal.AbstractFSWALProvider
- isMetaRegion() - Method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Returns true if this region is a meta region.
- isMetaRegion() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
Checks if this table is
hbase:meta
region. - isMetaRegionReplicaReplicationEnabled(Configuration, TableName) - Static method in class org.apache.hadoop.hbase.util.ServerRegionReplicaUtil
-
Returns True if hbase:meta Region Read Replica is enabled.
- isMetaTable() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
Checks if the table is a
hbase:meta
table - isMetaTableName(TableName) - Static method in class org.apache.hadoop.hbase.TableName
-
Returns True if
tn
is the hbase:meta table name. - isMetaZNodePath(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZNodePaths
-
Returns True is the fully qualified path is for meta location
- isMetaZNodePrefix(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZNodePaths
-
Returns True if meta znode.
- isMigration(Class<?>) - Static method in class org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileTrackerFactory
- isMinColumnInclusive() - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
-
Returns if min column range is inclusive.
- isMobEnabled() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Gets whether the mob is enabled for the family.
- isMobFile(Path) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
Checks if the file is a MOB file
- isMobFileExpired(ColumnFamilyDescriptor, long, String) - Static method in class org.apache.hadoop.hbase.mob.MobUtils
-
Checks if the mob file is expired.
- isMobReferenceCell(ExtendedCell) - Static method in class org.apache.hadoop.hbase.mob.MobUtils
-
Whether the current cell is a mob reference cell.
- isMobRefFile(Path) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
Checks if the file is a MOB reference file, created by snapshot
- isMobRegionInfo(RegionInfo) - Static method in class org.apache.hadoop.hbase.mob.MobUtils
-
Gets whether the current RegionInfo is a mob one.
- isMobRegionName(TableName, byte[]) - Static method in class org.apache.hadoop.hbase.mob.MobUtils
-
Gets whether the current region name follows the pattern of a mob region name.
- isMultiPut - Variable in class org.apache.hadoop.hbase.util.LoadTestTool
- isMultiPut - Variable in class org.apache.hadoop.hbase.util.MultiThreadedWriter
- isNamespaceRowKey(byte[]) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
- isNamespacesAndTableCFsEqual(ReplicationPeerConfig, ReplicationPeerConfig) - Static method in class org.apache.hadoop.hbase.replication.ReplicationUtils
- isNeedCursorResult() - Method in class org.apache.hadoop.hbase.client.ImmutableScan
- isNeedCursorResult() - Method in class org.apache.hadoop.hbase.client.Scan
- isNeedProcessConnectionHeader() - Method in class org.apache.hadoop.hbase.security.NettyHBaseSaslRpcClientHandler
- isNewKey(ExtendedCell) - Method in class org.apache.hadoop.hbase.util.BloomContext
-
Returns true if the cell is a new key as per the bloom type
- isNewKey(ExtendedCell) - Method in class org.apache.hadoop.hbase.util.RowBloomContext
- isNewKey(ExtendedCell) - Method in class org.apache.hadoop.hbase.util.RowColBloomContext
- isNewVersionBehavior() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
By default, HBase only consider timestamp in versions.
- isNewVersionBehavior() - Method in class org.apache.hadoop.hbase.regionserver.ScanInfo
- isNewVersionBehaviorEnabled() - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Check whether the tests should assume NEW_VERSION_BEHAVIOR when creating new column families.
- isNext(RegionInfo) - Method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Returns True if region is next, adjacent but 'after' this one.
- isNonDaemonThreadRunning() - Static method in class org.apache.hadoop.hbase.util.Threads
-
Checks whether any non-daemon thread is running.
- isNormalizationEnabled() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
Check if normalization enable flag of the table is true.
- isNormalizerEnabled() - Method in interface org.apache.hadoop.hbase.client.Admin
-
Query the current state of the region normalizer.
- isNormalizerEnabled() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Query the current state of the region normalizer
- isNormalizerEnabled(RpcController, MasterProtos.IsNormalizerEnabledRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- isNormalizerOn() - Method in class org.apache.hadoop.hbase.master.HMaster
-
Queries the state of the
RegionNormalizerStateStore
. - isNull() - Method in class org.apache.hadoop.hbase.quotas.QuotaFilter
-
Returns true if the filter is empty
- isNull(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Return true when the next encoded value in
src
is null, false otherwise. - isNullable() - Method in interface org.apache.hadoop.hbase.types.DataType
-
Indicates whether this instance supports encoding null values.
- isNullable() - Method in class org.apache.hadoop.hbase.types.FixedLengthWrapper
- isNullable() - Method in class org.apache.hadoop.hbase.types.OrderedBytesBase
- isNullable() - Method in class org.apache.hadoop.hbase.types.OrderedFloat32
- isNullable() - Method in class org.apache.hadoop.hbase.types.OrderedFloat64
- isNullable() - Method in class org.apache.hadoop.hbase.types.OrderedInt16
- isNullable() - Method in class org.apache.hadoop.hbase.types.OrderedInt32
- isNullable() - Method in class org.apache.hadoop.hbase.types.OrderedInt64
- isNullable() - Method in class org.apache.hadoop.hbase.types.OrderedInt8
- isNullable() - Method in class org.apache.hadoop.hbase.types.PBType
- isNullable() - Method in class org.apache.hadoop.hbase.types.RawByte
- isNullable() - Method in class org.apache.hadoop.hbase.types.RawBytes
- isNullable() - Method in class org.apache.hadoop.hbase.types.RawDouble
- isNullable() - Method in class org.apache.hadoop.hbase.types.RawFloat
- isNullable() - Method in class org.apache.hadoop.hbase.types.RawInteger
- isNullable() - Method in class org.apache.hadoop.hbase.types.RawLong
- isNullable() - Method in class org.apache.hadoop.hbase.types.RawShort
- isNullable() - Method in class org.apache.hadoop.hbase.types.RawString
- isNullable() - Method in class org.apache.hadoop.hbase.types.Struct
- isNullable() - Method in class org.apache.hadoop.hbase.types.TerminatedWrapper
- isNullable() - Method in class org.apache.hadoop.hbase.types.Union2
- isNullable() - Method in class org.apache.hadoop.hbase.types.Union3
- isNullable() - Method in class org.apache.hadoop.hbase.types.Union4
- isNumeric(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Return true when the next encoded value in
src
uses Numeric encoding, false otherwise. - isNumericInfinite(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Return true when the next encoded value in
src
uses Numeric encoding and isInfinite
, false otherwise. - isNumericNaN(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Return true when the next encoded value in
src
uses Numeric encoding and isNaN
, false otherwise. - isNumericZero(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Return true when the next encoded value in
src
uses Numeric encoding and is0
, false otherwise. - isOffHeap() - Method in class org.apache.hadoop.hbase.regionserver.ImmutableMemStoreLAB
- isOffHeap() - Method in interface org.apache.hadoop.hbase.regionserver.MemStoreLAB
- isOffHeap() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreLABImpl
- isOffheapMemStore() - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerContext
- isOffline() - Method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Deprecated.since 3.0.0 and will be removed in 4.0.0
- isOffline() - Method in class org.apache.hadoop.hbase.master.RegionState
- isolateRegionIdArray(List<String>) - Method in class org.apache.hadoop.hbase.util.RegionMover.RegionMoverBuilder
-
Set the region ID to isolate on the region server.
- isolateRegions() - Method in class org.apache.hadoop.hbase.util.RegionMover
-
Isolated regions specified in
RegionMover.isolateRegionIdArray
onRegionMover.hostname
in ack Mode and Unload regions from givenRegionMover.hostname
using ack/noAck mode andRegionMover.maxthreads
. - org.apache.hadoop.hbase.client.IsolationLevel - Enum Class in org.apache.hadoop.hbase.client
-
Specify Isolation levels in Scan operations.
- isOldMobFileName(String) - Static method in class org.apache.hadoop.hbase.mob.MobFileName
- isOnHeap() - Method in class org.apache.hadoop.hbase.regionserver.ImmutableMemStoreLAB
- isOnHeap() - Method in interface org.apache.hadoop.hbase.regionserver.MemStoreLAB
- isOnHeap() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreLABImpl
- isOnline() - Method in class org.apache.hadoop.hbase.master.HMaster
-
Report whether this master is started This method is used for testing.
- isOnline() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Report the status of the server.
- isOnline() - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupBasedLoadBalancer
- isOnline() - Method in interface org.apache.hadoop.hbase.rsgroup.RSGroupInfoManager
-
Whether the manager is able to fully return group metadata
- isOnServer(ServerName) - Method in class org.apache.hadoop.hbase.master.RegionState
- isOpened() - Method in class org.apache.hadoop.hbase.master.RegionState
- isOpenedOnServer(ServerName) - Method in class org.apache.hadoop.hbase.master.RegionState
- isOpening() - Method in class org.apache.hadoop.hbase.master.RegionState
- isOpeningOrFailedOpenOnServer(ServerName) - Method in class org.apache.hadoop.hbase.master.RegionState
- isOpeningOrOpenedOnServer(ServerName) - Method in class org.apache.hadoop.hbase.master.RegionState
- isOrderPreserving - Variable in class org.apache.hadoop.hbase.types.Struct
- isOrderPreserving() - Method in interface org.apache.hadoop.hbase.types.DataType
-
Indicates whether this instance writes encoded
byte[]
's which preserve the natural sort order of the unencoded value. - isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.FixedLengthWrapper
- isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.OrderedBytesBase
- isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.PBType
- isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.RawByte
- isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.RawBytes
- isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.RawDouble
- isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.RawFloat
- isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.RawInteger
- isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.RawLong
- isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.RawShort
- isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.RawString
- isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.Struct
- isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.TerminatedWrapper
- isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.Union2
- isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.Union3
- isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.Union4
- isOrphan() - Method in class org.apache.hadoop.hbase.master.SplitLogManager.Task
-
Deprecated.
- isOverlap(RegionInfo) - Method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Returns True if an overlap in region range.
- isOverwrite() - Method in class org.apache.hadoop.hbase.backup.RestoreRequest
- isOwned() - Method in class org.apache.hadoop.hbase.SplitLogTask
-
Deprecated.
- isOwned(ServerName) - Method in class org.apache.hadoop.hbase.SplitLogTask
-
Deprecated.
- isPBMagicPrefix(byte[]) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Returns True if passed
bytes
hasProtobufMagic.PB_MAGIC
for a prefix. - isPBMagicPrefix(byte[], int, int) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Returns True if passed
bytes
hasProtobufMagic.PB_MAGIC
for a prefix. - isPeerEnabled() - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeer
-
Test whether the peer is enabled.
- isPeerEnabled(String) - Method in class org.apache.hadoop.hbase.replication.FSReplicationPeerStorage
- isPeerEnabled(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeerStorage
-
Test whether a replication peer is enabled.
- isPeerEnabled(String) - Method in class org.apache.hadoop.hbase.replication.ZKReplicationPeerStorage
- isPeriodic() - Method in class org.apache.hadoop.hbase.JitterScheduledThreadPoolExecutorImpl.JitteredRunnableScheduledFuture
- isPluggableQueueType(String) - Static method in class org.apache.hadoop.hbase.ipc.RpcExecutor
- isPluggableQueueWithFastPath(String, Configuration) - Static method in class org.apache.hadoop.hbase.ipc.RpcExecutor
- isPreadAllBytes() - Method in class org.apache.hadoop.hbase.io.hfile.ReaderContext
- isPrefetchBlocksOnOpen() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Returns true if we should prefetch blocks into the blockcache on open
- isPrimary() - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheKey
- isPrimaryReplicaReader() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
- isPrimaryReplicaReader() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
- isPrimaryReplicaReader() - Method in class org.apache.hadoop.hbase.io.hfile.ReaderContext
- isPrimaryReplicaReader() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileReader
- isPrimaryReplicaStore() - Method in class org.apache.hadoop.hbase.regionserver.HStore
- isPrimaryReplicaStore() - Method in interface org.apache.hadoop.hbase.regionserver.Store
- isPrimaryReplicaStore() - Method in class org.apache.hadoop.hbase.regionserver.StoreContext
- isProcedureDone(RpcController, MasterProtos.IsProcedureDoneRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
Checks if the specified procedure is done.
- isProcedureFinished(String, String, Map<String, String>) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Check the current state of the specified procedure.
- isProcedureFinished(String, String, Map<String, String>) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Check the current state of the specified procedure.
- isProcessed() - Method in class org.apache.hadoop.hbase.client.SingleResponse.Entry
- isPut(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Returns True if this cell is a Put.
- isQueueRecovered() - Method in class org.apache.hadoop.hbase.replication.ReplicationQueueInfo
- isQuotaEnabled(Configuration) - Static method in class org.apache.hadoop.hbase.quotas.QuotaUtil
-
Returns true if the support for quota is enabled
- isQuotaInitialized() - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
- isQuoteUnescaped(byte[], int) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Returns a boolean indicating whether the quote was escaped or not
- isRaw() - Method in class org.apache.hadoop.hbase.client.ImmutableScan
- isRaw() - Method in class org.apache.hadoop.hbase.client.Scan
-
Returns True if this Scan is in "raw" mode.
- isRawMobScan(Scan) - Static method in class org.apache.hadoop.hbase.mob.MobUtils
-
Indicates whether it's a raw scan.
- isRead - Variable in class org.apache.hadoop.hbase.util.LoadTestTool
- isReadEmptyValueOnMobCellMiss(Scan) - Static method in class org.apache.hadoop.hbase.mob.MobUtils
-
Indicates whether return null value when the mob file is missing or corrupt.
- isReadOnly() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
Check if the readOnly flag of the table is set.
- isReadOnly() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
- isReadOnly() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Returns True if region is read only
- isReadOnly(HRegion) - Static method in class org.apache.hadoop.hbase.util.ServerRegionReplicaUtil
-
Returns whether this region replica can accept writes.
- isReadShortCircuitOn() - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Get the HBase setting for dfs.client.read.shortcircuit from the conf or a system property.
- isReady() - Method in interface org.apache.hadoop.hbase.coordination.SplitLogWorkerCoordination
-
Deprecated.Check whether the log splitter is ready to supply tasks
- isReady() - Method in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination
- isReadyToOffline() - Method in class org.apache.hadoop.hbase.master.RegionState
-
Check if a region state can transition to offline
- isReadyToOnline() - Method in class org.apache.hadoop.hbase.master.RegionState
-
Check if a region state can transition to online
- isRecovered() - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSource
- isRecovered() - Method in class org.apache.hadoop.hbase.replication.ReplicationQueueId
- isRecoveredEdits(Path) - Static method in class org.apache.hadoop.hbase.util.CommonFSUtils
-
Checks if the given path is the one with 'recovered.edits' dir.
- isRecoverySupported() - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputCommitter
- isReference() - Method in class org.apache.hadoop.hbase.regionserver.HStoreFile
- isReference() - Method in interface org.apache.hadoop.hbase.regionserver.StoreFile
-
Returns True if this is a StoreFile Reference.
- isReference() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
Returns True if the store file is a Reference
- isReference(String) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
- isReference(Path) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
- isReferencedInReads() - Method in class org.apache.hadoop.hbase.regionserver.HStoreFile
-
Returns true if the file is still used in reads
- isRefOnlyScan(Scan) - Static method in class org.apache.hadoop.hbase.mob.MobUtils
-
Indicates whether it's a reference only scan.
- isRegionCloseMarker() - Method in class org.apache.hadoop.hbase.wal.WALEdit
-
Public so can be accessed from regionserver.wal package.
- isRegionInServerManagerStates(RegionInfo) - Method in class org.apache.hadoop.hbase.master.ServerManager
- isRegionReplicaReplicationEnabled(Configuration, TableName) - Static method in class org.apache.hadoop.hbase.util.ServerRegionReplicaUtil
- isRegionReplicaStoreFileRefreshEnabled(Configuration) - Static method in class org.apache.hadoop.hbase.util.ServerRegionReplicaUtil
-
Returns True if we are to refresh user-space hfiles in Region Read Replicas.
- isRegionReplicaWaitForPrimaryFlushEnabled(Configuration) - Static method in class org.apache.hadoop.hbase.util.ServerRegionReplicaUtil
-
Returns True if wait for primary to flush is enabled for user-space tables.
- isRegionServerRowKey(byte[]) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
- isRegionStale(String, long) - Method in class org.apache.hadoop.hbase.regionserver.StorefileRefresherChore
- isRemote() - Method in exception org.apache.hadoop.hbase.errorhandling.ForeignException
-
The cause of a ForeignException can be an exception that was generated on a local in process thread, or a thread from a 'remote' separate process.
- isReplay() - Method in class org.apache.hadoop.hbase.wal.WALEdit
- isReplicasForSameRegion(RegionInfo, RegionInfo) - Static method in class org.apache.hadoop.hbase.client.RegionReplicaUtil
- isReplicationForBulkLoadDataEnabled(Configuration) - Static method in class org.apache.hadoop.hbase.replication.ReplicationUtils
- isReplicationMarkerEdit(WALEdit) - Static method in class org.apache.hadoop.hbase.wal.WALEdit
-
Checks whether this edit is a replication marker edit.
- isReplicationPeerEnabled(String) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Check if a replication peer is enabled.
- isReplicationPeerEnabled(String) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Check if a replication peer is enabled.
- isReplicationPeerEnabled(RpcController, ReplicationProtos.GetReplicationPeerStateRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- isReplicationPeerModificationEnabled() - Method in interface org.apache.hadoop.hbase.client.Admin
-
Check whether replication peer modification is enabled.
- isReplicationPeerModificationEnabled() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Check whether replication peer modification is enabled.
- isReplicationPeerModificationEnabled() - Method in class org.apache.hadoop.hbase.master.HMaster
- isReplicationPeerModificationEnabled() - Method in interface org.apache.hadoop.hbase.master.MasterServices
- isReplicationPeerModificationEnabled(RpcController, ReplicationProtos.IsReplicationPeerModificationEnabledRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- isReplicationQueueTable(Configuration, TableName) - Static method in class org.apache.hadoop.hbase.replication.ReplicationStorageFactory
- isRescanNode(String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog
-
Deprecated.
- isRescanNode(ZKWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog
-
Deprecated.Checks if the given path represents a rescan node.
- isReservedFileInfoKey(byte[]) - Static method in class org.apache.hadoop.hbase.io.hfile.HFileInfo
-
Return true if the given file info key is reserved for internal use.
- isReservoirEnabled() - Method in class org.apache.hadoop.hbase.io.ByteBuffAllocator
- isResigned() - Method in class org.apache.hadoop.hbase.SplitLogTask
-
Deprecated.
- isResigned(ServerName) - Method in class org.apache.hadoop.hbase.SplitLogTask
-
Deprecated.
- isRetry() - Method in class org.apache.hadoop.hbase.util.RetryCounter
- isRetryImmediatelySupported() - Method in interface org.apache.hadoop.hbase.ipc.RpcCallContext
- isRetryImmediatelySupported() - Method in class org.apache.hadoop.hbase.ipc.ServerCall
- isReturnResults() - Method in class org.apache.hadoop.hbase.client.Append
-
Returns current setting for returnResults
- isReturnResults() - Method in class org.apache.hadoop.hbase.client.Increment
-
Returns current setting for returnResults
- isReturnResults() - Method in class org.apache.hadoop.hbase.client.Mutation
-
Returns current value for returnResults
- isReverse() - Method in class org.apache.hadoop.hbase.hbtop.terminal.Attributes
- isReverse() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.Cell
- isReversed() - Method in class org.apache.hadoop.hbase.client.ImmutableScan
- isReversed() - Method in class org.apache.hadoop.hbase.client.Scan
-
Get whether this scan is a reversed one.
- isReversed() - Method in class org.apache.hadoop.hbase.filter.Filter
- isReversed() - Method in class org.apache.hadoop.hbase.filter.FilterList
- isRollbackSupported(MasterProcedureProtos.ModifyStoreFileTrackerState) - Method in class org.apache.hadoop.hbase.regionserver.storefiletracker.ModifyStoreFileTrackerProcedure
- isRollRequested() - Method in class org.apache.hadoop.hbase.wal.AbstractWALRoller.RollController
- isRpcThrottleEnabled() - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get if the rpc throttle is enabled.
- isRpcThrottleEnabled() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Get if the rpc throttle is enabled.
- isRpcThrottleEnabled() - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
- isRpcThrottleEnabled() - Method in class org.apache.hadoop.hbase.quotas.RegionServerRpcQuotaManager
- isRpcThrottleEnabled() - Method in class org.apache.hadoop.hbase.quotas.RpcThrottleStorage
- isRpcThrottleEnabled(MasterProtos.IsRpcThrottleEnabledRequest) - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
- isRpcThrottleEnabled(RpcController, MasterProtos.IsRpcThrottleEnabledRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- isRSGroupEnabled(Configuration) - Static method in class org.apache.hadoop.hbase.rsgroup.RSGroupUtil
- isRunning() - Method in interface org.apache.hadoop.hbase.master.MetricsMasterWrapper
-
Returns if the master is currently running and is not attempting to shutdown.
- isRunning() - Method in class org.apache.hadoop.hbase.master.MetricsMasterWrapperImpl
- isRunning() - Method in interface org.apache.hadoop.hbase.replication.ReplicationEndpoint
-
Returns
true
if this service is RUNNING. - isRunning() - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSource
- isSameAddress(ServerName, ServerName) - Static method in class org.apache.hadoop.hbase.ServerName
-
Compare two addresses
- isSameHdfs(Configuration, FileSystem, FileSystem) - Static method in class org.apache.hadoop.hbase.util.FSUtils
- isScanMetricsEnabled() - Method in class org.apache.hadoop.hbase.client.ImmutableScan
- isScanMetricsEnabled() - Method in class org.apache.hadoop.hbase.client.Scan
-
Returns True if collection of scan metrics is enabled.
- isScheduled() - Method in class org.apache.hadoop.hbase.ScheduledChore
-
Returns true when this Chore is scheduled with a ChoreService
- isSearchRowInclusive() - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.RowRange
- isSecure() - Method in class org.apache.hadoop.hbase.http.HttpConfig
- isSecureZooKeeper(Configuration) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAuthentication
-
Returns
true
when secure authentication is enabled (whetherhbase.security.authentication
is set to "kerberos
"). - isSecurityAvailable(Configuration) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
- isSecurityEnabled - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
- isSecurityEnabled() - Static method in class org.apache.hadoop.hbase.security.User
-
Returns whether or not Kerberos authentication is configured for Hadoop.
- isSecurityEnabled() - Static method in class org.apache.hadoop.hbase.security.User.SecureHadoopUser
-
Returns the result of
UserGroupInformation.isSecurityEnabled()
. - isSeeked() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.EncodedScanner
- isSeeked() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
- isSeeked() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
- isSequenceIdFile(Path) - Static method in class org.apache.hadoop.hbase.wal.WALSplitUtil
-
Is the given file a region open sequence id file.
- isSerial() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
- isServerDead(ServerName) - Method in class org.apache.hadoop.hbase.master.ServerManager
-
Check if a server is known to be dead.
- isServerKnownAndOnline(ServerName) - Method in class org.apache.hadoop.hbase.master.ServerManager
-
Returns whether the server is online, dead, or unknown.
- isServerOnline(ServerName) - Method in class org.apache.hadoop.hbase.master.ServerManager
- isServerOverloaded() - Method in exception org.apache.hadoop.hbase.HBaseServerException
-
Returns True if server was considered overloaded when exception was thrown
- isServerOverloaded() - Method in exception org.apache.hadoop.hbase.ipc.RemoteWithExtrasException
-
Returns True if the server was considered overloaded when the exception was thrown.
- isServerOverloaded(Throwable) - Static method in exception org.apache.hadoop.hbase.HBaseServerException
-
Returns True if the server was considered overloaded when the exception was thrown
- isServerUnknown(ServerName) - Method in class org.apache.hadoop.hbase.master.ServerManager
-
Check if a server is unknown.
- isSharedMem() - Method in class org.apache.hadoop.hbase.io.hfile.ExclusiveMemHFileBlock
- isSharedMem() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
Will be override by
SharedMemHFileBlock
orExclusiveMemHFileBlock
. - isSharedMem() - Method in class org.apache.hadoop.hbase.io.hfile.SharedMemHFileBlock
- isShift() - Method in class org.apache.hadoop.hbase.hbtop.terminal.KeyPress
- isShowConfInServlet() - Static method in class org.apache.hadoop.hbase.HBaseConfiguration
-
Returns whether to show HBase Configuration in servlet
- isShutdown() - Method in class org.apache.hadoop.hbase.ChoreService
-
Returns true when the service is shutdown and thus cannot be used anymore
- isShutdownHookInstalled() - Method in class org.apache.hadoop.hbase.HBaseServerBase
- isSingleRow() - Method in class org.apache.hadoop.hbase.rest.RowSpec
- isSkipChecks() - Method in class org.apache.hadoop.hbase.util.HbckRegionInfo
- isSkipInit - Variable in class org.apache.hadoop.hbase.util.LoadTestTool
- isSkippable - Variable in class org.apache.hadoop.hbase.types.Struct
- isSkippable() - Method in interface org.apache.hadoop.hbase.types.DataType
-
Indicates whether this instance is able to skip over it's encoded value.
- isSkippable() - Method in class org.apache.hadoop.hbase.types.FixedLengthWrapper
- isSkippable() - Method in class org.apache.hadoop.hbase.types.OrderedBlob
- isSkippable() - Method in class org.apache.hadoop.hbase.types.OrderedBytesBase
- isSkippable() - Method in class org.apache.hadoop.hbase.types.PBType
- isSkippable() - Method in class org.apache.hadoop.hbase.types.RawByte
- isSkippable() - Method in class org.apache.hadoop.hbase.types.RawBytes
- isSkippable() - Method in class org.apache.hadoop.hbase.types.RawDouble
- isSkippable() - Method in class org.apache.hadoop.hbase.types.RawFloat
- isSkippable() - Method in class org.apache.hadoop.hbase.types.RawInteger
- isSkippable() - Method in class org.apache.hadoop.hbase.types.RawLong
- isSkippable() - Method in class org.apache.hadoop.hbase.types.RawShort
- isSkippable() - Method in class org.apache.hadoop.hbase.types.RawString
- isSkippable() - Method in class org.apache.hadoop.hbase.types.Struct
- isSkippable() - Method in class org.apache.hadoop.hbase.types.TerminatedWrapper
- isSkippable() - Method in class org.apache.hadoop.hbase.types.Union2
- isSkippable() - Method in class org.apache.hadoop.hbase.types.Union3
- isSkippable() - Method in class org.apache.hadoop.hbase.types.Union4
- isSloppy() - Method in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
- isSloppy() - Method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore
- isSloppy() - Method in interface org.apache.hadoop.hbase.regionserver.MemStore
- isSloppyMemStore() - Method in class org.apache.hadoop.hbase.regionserver.HStore
- isSloppyMemStore() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Returns true if the memstore may need some extra memory space
- isSlowLog() - Method in class org.apache.hadoop.hbase.namequeues.RpcLogDetails
- isSnapshotCleanupEnabled() - Method in interface org.apache.hadoop.hbase.client.Admin
-
Query the current state of the auto snapshot cleanup based on TTL.
- isSnapshotCleanupEnabled() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Query the current state of the auto snapshot cleanup based on TTL.
- isSnapshotCleanupEnabled(RpcController, MasterProtos.IsSnapshotCleanupEnabledRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- isSnapshotCorrupted() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
-
Returns true if the snapshot is corrupted
- isSnapshotDone(RpcController, MasterProtos.IsSnapshotDoneRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
Checks if the specified snapshot is done.
- isSnapshotFinished(SnapshotDescription) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Check the current state of the passed snapshot.
- isSnapshotFinished(SnapshotDescription) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Check the current state of the passed snapshot.
- isSnapshotOwner(SnapshotDescription, User) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
Check if the user is this table snapshot's owner
- isSorted(Collection<byte[]>) - Static method in class org.apache.hadoop.hbase.util.Bytes
- isSpecialException(Throwable) - Static method in class org.apache.hadoop.hbase.exceptions.ClientExceptionsUtil
- isSplit() - Method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Returns True if has been split and has daughters.
- isSplit() - Method in class org.apache.hadoop.hbase.master.RegionState
- isSplitable(JobContext, Path) - Method in class org.apache.hadoop.hbase.mapreduce.HFileInputFormat
- isSplitEnabled() - Method in interface org.apache.hadoop.hbase.client.Admin
-
Query the current state of the split switch.
- isSplitEnabled() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Query the current state of the Split switch.
- isSplitEnabled() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
Check if the split enable flag of the table is true.
- isSplitOrMergeEnabled(MasterSwitchType) - Method in class org.apache.hadoop.hbase.master.HMaster
-
Queries the state of the
SplitOrMergeStateStore
. - isSplitOrMergeEnabled(MasterSwitchType) - Method in interface org.apache.hadoop.hbase.master.MasterServices
- isSplitOrMergeEnabled(MasterSwitchType) - Method in class org.apache.hadoop.hbase.master.SplitOrMergeStateStore
- isSplitOrMergeEnabled(RpcController, MasterProtos.IsSplitOrMergeEnabledRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- isSplitParent() - Method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Deprecated.since 3.0.0 and will be removed in 4.0.0, Use
RegionInfo.isSplit()
instead. - isSplittable() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
- isSplittable() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Returns true if region is splittable
- isSplitting() - Method in class org.apache.hadoop.hbase.master.RegionState
- isSplittingNew() - Method in class org.apache.hadoop.hbase.master.RegionState
- isSplittingNewOnServer(ServerName) - Method in class org.apache.hadoop.hbase.master.RegionState
- isSplittingOnServer(ServerName) - Method in class org.apache.hadoop.hbase.master.RegionState
- isSplittingOrOpenedOnServer(ServerName) - Method in class org.apache.hadoop.hbase.master.RegionState
- isSplittingOrSplitOnServer(ServerName) - Method in class org.apache.hadoop.hbase.master.RegionState
- isSplitWALFinished(String) - Method in class org.apache.hadoop.hbase.master.SplitWALManager
- isStale() - Method in class org.apache.hadoop.hbase.client.Result
-
Whether or not the results are coming from possibly stale data.
- isStarted() - Method in class org.apache.hadoop.hbase.ipc.RpcServer
- isStarted() - Method in interface org.apache.hadoop.hbase.ipc.RpcServerInterface
- isStarted() - Method in class org.apache.hadoop.hbase.quotas.RegionServerSpaceQuotaManager
-
Returns if the
Chore
has been started. - isStarting() - Method in class org.apache.hadoop.hbase.replication.BaseReplicationEndpoint
- isStarting() - Method in interface org.apache.hadoop.hbase.replication.ReplicationEndpoint
-
Returns Return
true
is this service is STARTING (but not yet RUNNING). - isStartingWithPath(Path, String) - Static method in class org.apache.hadoop.hbase.util.CommonFSUtils
-
Compare of path component.
- isStartRowInclusive() - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.RowRange
-
Returns if start row is inclusive.
- isSticky() - Method in class org.apache.hadoop.hbase.rest.client.Client
-
The default behaviour is load balancing by sending each request to a random host.
- isStop() - Method in interface org.apache.hadoop.hbase.coordination.SplitLogWorkerCoordination
-
Deprecated.Returns the current value of exitWorker
- isStop() - Method in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination
- isStopped() - Method in class org.apache.hadoop.hbase.backup.BackupHFileCleaner
- isStopped() - Method in class org.apache.hadoop.hbase.HBaseServerBase
- isStopped() - Method in class org.apache.hadoop.hbase.MockRegionServerServices
- isStopped() - Method in class org.apache.hadoop.hbase.quotas.QuotaCache
- isStopped() - Method in class org.apache.hadoop.hbase.regionserver.throttle.NoLimitThroughputController
- isStopped() - Method in class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareThroughputController
- isStopped() - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupBasedLoadBalancer
- isStopped() - Method in interface org.apache.hadoop.hbase.Stoppable
-
Returns True if
Stoppable.stop(String)
has been closed. - isStopping() - Method in class org.apache.hadoop.hbase.MockRegionServerServices
- isStopping() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
- isStopping() - Method in interface org.apache.hadoop.hbase.Server
-
Returns True is the server is Stopping
- isStopRowInclusive() - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.RowRange
-
Returns if stop row is inclusive.
- isSubDirectoryOf(Path, Path) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
Determines if the given workingDir is a subdirectory of the given "root directory"
- isSuccess() - Method in class org.apache.hadoop.hbase.client.CheckAndMutateResult
-
Returns Whether the CheckAndMutate operation is successful or not
- isSuperUser(String) - Static method in class org.apache.hadoop.hbase.security.Superusers
-
Check if the current user is a super user
- isSuperUser(User) - Static method in class org.apache.hadoop.hbase.security.Superusers
-
Check if the current user is a super user
- isSuperUserId(String[], Id) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKWatcher
- isSyncReplication() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
-
Use remote wal dir to decide whether a peer is sync replication peer
- isSystemTable() - Method in class org.apache.hadoop.hbase.TableName
- isTableAvailable(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Check if a table is available.
- isTableAvailable(TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Check if a table is available.
- isTableDir(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSTableDescriptors
-
Check whether we have a valid TableDescriptor.
- isTableDisabled(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Check if a table is disabled.
- isTableDisabled(TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Check if a table is disabled.
- isTableEnabled(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
- isTableEnabled(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Check if a table is enabled.
- isTableEnabled(TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Check if a table is enabled.
- isTablePresent(TableName) - Method in class org.apache.hadoop.hbase.master.TableStateManager
- isTableRowKey(byte[]) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
- isTableState(TableName, TableState.State...) - Method in class org.apache.hadoop.hbase.master.TableStateManager
- isTagsPresent() - Method in class org.apache.hadoop.hbase.regionserver.CompositeImmutableSegment
- isTagsPresent() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreSnapshot
-
Returns true if tags are present in this snapshot
- isTagsPresent() - Method in class org.apache.hadoop.hbase.regionserver.Segment
- isTcpNoDelay() - Method in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
- isTerminated() - Method in class org.apache.hadoop.hbase.ChoreService
-
Returns true when the service is shutdown and all threads have terminated
- isText(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Return true when the next encoded value in
src
uses Text encoding, false otherwise. - isTop() - Method in class org.apache.hadoop.hbase.io.HalfStoreFileReader
- isTopFileRegion(Reference.Range) - Static method in class org.apache.hadoop.hbase.io.Reference
- isTopReference() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
Returns True if the store file is a top Reference
- isTrackingMetrics() - Method in class org.apache.hadoop.hbase.regionserver.ScannerContext
- isUnassignable() - Method in class org.apache.hadoop.hbase.master.RegionState
-
Check if a region state is one of offline states that can't transition to pending_close/closing (unassign/offline)
- isUnassignable(RegionState.State) - Static method in class org.apache.hadoop.hbase.master.RegionState
-
Check if a region state is one of offline states that can't transition to pending_close/closing (unassign/offline)
- isUnassigned() - Method in class org.apache.hadoop.hbase.master.SplitLogManager.Task
-
Deprecated.
- isUnassigned() - Method in class org.apache.hadoop.hbase.SplitLogTask
-
Deprecated.
- isUnassigned(ServerName) - Method in class org.apache.hadoop.hbase.SplitLogTask
-
Deprecated.
- isUnderCompaction(HStore) - Method in class org.apache.hadoop.hbase.regionserver.CompactSplit
-
Check if this store is under compaction
- isUnderline() - Method in class org.apache.hadoop.hbase.hbtop.terminal.Attributes
- isUnderline() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.Cell
- isUnexpectedPreambleHeaderException(IOException) - Static method in class org.apache.hadoop.hbase.client.ConnectionUtils
- isUnix() - Static method in class org.apache.hadoop.hbase.util.JVM
-
Check if the OS is unix.
- isUnpacked() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
Return true when this block's buffer has been unpacked, false otherwise.
- isUpdate - Variable in class org.apache.hadoop.hbase.util.LoadTestTool
- isUsecache() - Method in class org.apache.hadoop.hbase.util.FSTableDescriptors
- isUseHBaseChecksum() - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
- isUserRowKey(byte[]) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
- isUserScan() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.CompactionScanQueryMatcher
- isUserScan() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher
- isUserScan() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.UserScanQueryMatcher
- isUsingL0Flush() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreConfig
- isValid() - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.RowRange
- isValid(FileStatus) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
Return if the specified file is a valid store file or not.
- isValidArguements(String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.ExportUtils
- isValidName(String) - Method in class org.apache.hadoop.hbase.util.FSUtils.BlackListDirFilter
- isValidName(String) - Method in class org.apache.hadoop.hbase.util.FSUtils.UserTableDirFilter
- isValidProtocol(String) - Static method in class org.apache.hadoop.hbase.http.log.LogLevel
- isValidState(ScannerContext.NextState) - Static method in enum class org.apache.hadoop.hbase.regionserver.ScannerContext.NextState
- isVerbose - Variable in class org.apache.hadoop.hbase.util.LoadTestTool
- isWALTrailer(long) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractProtobufWALReader
-
This is used to determine whether we have already reached the WALTrailer.
- isWithinDefaultWorkingDir(Path, Configuration) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
Determines if the given workingDir is a subdirectory of the default working snapshot directory
- isWritabilityBackpressureEnabled() - Method in class org.apache.hadoop.hbase.ipc.NettyRpcServer
- isWrite - Variable in class org.apache.hadoop.hbase.util.LoadTestTool
- isWriteable(Class<?>, Type, Annotation[], MediaType) - Method in class org.apache.hadoop.hbase.http.gson.GsonMessageBodyWriter
- isWriterBroken() - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
- isWriteRequest(RPCProtos.RequestHeader, Message) - Method in class org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
- iter - Variable in class org.apache.hadoop.hbase.regionserver.SegmentScanner
- iterateOnSplits(byte[], byte[], boolean, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Iterate over keys within the passed range.
- iterateOnSplits(byte[], byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Iterate over keys within the passed range, splitting at an [a,b) boundary.
- iterator() - Method in interface org.apache.hadoop.hbase.client.ResultScanner
- iterator() - Method in class org.apache.hadoop.hbase.CompoundConfiguration
- iterator() - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
- iterator() - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCache
-
Returns Iterator over the blocks in the cache.
- iterator() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
- iterator() - Method in class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache
- iterator() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
- iterator() - Method in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
- iterator() - Method in class org.apache.hadoop.hbase.io.hfile.TinyLfuBlockCache
- iterator() - Method in class org.apache.hadoop.hbase.ipc.AdaptiveLifoCoDelCallQueue
- iterator() - Method in class org.apache.hadoop.hbase.quotas.NoOpRegionSizeStore
- iterator() - Method in class org.apache.hadoop.hbase.quotas.QuotaRetriever
- iterator() - Method in class org.apache.hadoop.hbase.quotas.RegionSizeStoreImpl
- iterator() - Method in class org.apache.hadoop.hbase.RegionLocations
- iterator() - Method in class org.apache.hadoop.hbase.regionserver.CellSet
- iterator() - Method in class org.apache.hadoop.hbase.regionserver.CompositeImmutableSegment
- iterator() - Method in class org.apache.hadoop.hbase.regionserver.Segment
- iterator() - Method in class org.apache.hadoop.hbase.thrift.CallQueue
- iterator() - Method in class org.apache.hadoop.hbase.util.BoundedPriorityBlockingQueue
- iterator() - Method in class org.apache.hadoop.hbase.util.ConcatenatedLists
- iterator() - Method in class org.apache.hadoop.hbase.util.PairOfSameType
- iterator() - Method in class org.apache.hadoop.hbase.util.SortedList
- iterator(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.Struct
-
Retrieve an
Iterator
over the values encoded insrc
. - Iterator() - Constructor for class org.apache.hadoop.hbase.util.ConcatenatedLists.Iterator
- iterNext - Variable in class org.apache.hadoop.hbase.util.AvlUtil.AvlLinkedNode
- iterPrev - Variable in class org.apache.hadoop.hbase.util.AvlUtil.AvlLinkedNode
- IV_LENGTH - Static variable in class org.apache.hadoop.hbase.io.crypto.Cipher
J
- jarDir(File, String, ZipOutputStream) - Static method in class org.apache.hadoop.hbase.mapreduce.JarFinder
- org.apache.hadoop.hbase.mapreduce.JarFinder - Class in org.apache.hadoop.hbase.mapreduce
-
Finds the Jar for a class.
- JAVA - Enum constant in enum class org.apache.hadoop.hbase.filter.RegexStringComparator.EngineType
- JAVA_LANG_DOMAIN - Static variable in class org.apache.hadoop.hbase.util.JSONMetricUtil
- JAVA_NIO_DOMAIN - Static variable in class org.apache.hadoop.hbase.util.JSONMetricUtil
- JENKINS_HASH - Static variable in class org.apache.hadoop.hbase.util.Hash
-
Constant to denote
JenkinsHash
. - org.apache.hadoop.hbase.util.JenkinsHash - Class in org.apache.hadoop.hbase.util
-
Produces 32-bit hash for hash table lookup.
- JenkinsHash() - Constructor for class org.apache.hadoop.hbase.util.JenkinsHash
- org.apache.hadoop.hbase.JitterScheduledThreadPoolExecutorImpl - Class in org.apache.hadoop.hbase
-
ScheduledThreadPoolExecutor that will add some jitter to the RunnableScheduledFuture.getDelay.
- JitterScheduledThreadPoolExecutorImpl(int, ThreadFactory, double) - Constructor for class org.apache.hadoop.hbase.JitterScheduledThreadPoolExecutorImpl
-
Main constructor.
- org.apache.hadoop.hbase.JitterScheduledThreadPoolExecutorImpl.JitteredRunnableScheduledFuture<V> - Class in org.apache.hadoop.hbase
-
Class that basically just defers to the wrapped future.
- JKS - Enum constant in enum class org.apache.hadoop.hbase.io.crypto.tls.KeyStoreFileType
- JMX_CONTEXT - Static variable in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
- org.apache.hadoop.hbase.http.jmx.JMXJsonServlet - Class in org.apache.hadoop.hbase.http.jmx
-
Provides Read only web access to JMX.
- JMXJsonServlet() - Constructor for class org.apache.hadoop.hbase.http.jmx.JMXJsonServlet
- org.apache.hadoop.hbase.JMXListener - Class in org.apache.hadoop.hbase
-
Pluggable JMX Agent for HBase(to fix the 2 random TCP ports issue of the out-of-the-box JMX Agent): 1)connector port can share with the registry port if SSL is OFF 2)support password authentication 3)support subset of SSL (with default configuration)
- JMXListener() - Constructor for class org.apache.hadoop.hbase.JMXListener
- JOB_NAME_CONF_KEY - Static variable in interface org.apache.hadoop.hbase.backup.BackupRestoreConstants
- JOB_NAME_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv
- org.apache.hadoop.hbase.mapreduce.JobUtil - Class in org.apache.hadoop.hbase.mapreduce
-
Utility methods to interact with a job.
- JobUtil() - Constructor for class org.apache.hadoop.hbase.mapreduce.JobUtil
- join() - Method in class org.apache.hadoop.hbase.client.example.HttpProxyExample
- join() - Method in class org.apache.hadoop.hbase.http.HttpServer
- join() - Method in class org.apache.hadoop.hbase.ipc.NettyRpcServer
- join() - Method in interface org.apache.hadoop.hbase.ipc.RpcServerInterface
- join() - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcServer
-
Deprecated.Wait for the server to be stopped.
- join() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
Wait for Mini HBase Cluster to shut down.
- join() - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.Wait for Mini HBase Cluster to shut down.
- join() - Method in class org.apache.hadoop.hbase.rest.RESTServer
- JOINER - Static variable in class org.apache.hadoop.hbase.util.Strings
- joinZNode(String, String...) - Static method in class org.apache.hadoop.hbase.zookeeper.ZNodePaths
-
Join the prefix znode name with the suffix znode name to generate a proper full znode name.
- JONI - Enum constant in enum class org.apache.hadoop.hbase.filter.RegexStringComparator.EngineType
- org.apache.hadoop.hbase.util.JRubyFormat - Class in org.apache.hadoop.hbase.util
-
Utility class for converting objects to JRuby.
- org.apache.hadoop.hbase.util.JSONBean - Class in org.apache.hadoop.hbase.util
-
Utility for doing JSON and MBeans.
- JSONBean() - Constructor for class org.apache.hadoop.hbase.util.JSONBean
- org.apache.hadoop.hbase.util.JSONBean.Writer - Interface in org.apache.hadoop.hbase.util
-
Use dumping out mbeans as JSON.
- jsonBeanWriter - Variable in class org.apache.hadoop.hbase.http.jmx.JMXJsonServlet
- org.apache.hadoop.hbase.util.JsonMapper - Class in org.apache.hadoop.hbase.util
-
Utility class for converting objects to JSON
- org.apache.hadoop.hbase.util.JSONMetricUtil - Class in org.apache.hadoop.hbase.util
- org.apache.hadoop.hbase.logging.JulToSlf4jInitializer - Class in org.apache.hadoop.hbase.logging
-
Setup
SLF4JBridgeHandler
. - JulToSlf4jInitializer() - Constructor for class org.apache.hadoop.hbase.logging.JulToSlf4jInitializer
- JUMBO_CHUNK - Enum constant in enum class org.apache.hadoop.hbase.regionserver.ChunkCreator.ChunkType
- org.apache.hadoop.hbase.util.JVM - Class in org.apache.hadoop.hbase.util
-
This class is a wrapper for the implementation of com.sun.management.UnixOperatingSystemMXBean It will decide to use the sun api or its own implementation depending on the runtime (vendor) used.
- JVM() - Constructor for class org.apache.hadoop.hbase.util.JVM
-
Constructor.
- org.apache.hadoop.hbase.util.JVMClusterUtil - Class in org.apache.hadoop.hbase.util
-
Utility used running a cluster all in the one JVM.
- JVMClusterUtil() - Constructor for class org.apache.hadoop.hbase.util.JVMClusterUtil
- org.apache.hadoop.hbase.util.JVMClusterUtil.MasterThread - Class in org.apache.hadoop.hbase.util
-
Datastructure to hold Master Thread and Master instance
- org.apache.hadoop.hbase.util.JVMClusterUtil.RegionServerThread - Class in org.apache.hadoop.hbase.util
-
Datastructure to hold RegionServer Thread and RegionServer instance
- org.apache.hadoop.hbase.util.JvmPauseMonitor - Class in org.apache.hadoop.hbase.util
-
Class which sets up a simple thread which runs in a loop sleeping for a short interval of time.
- JvmPauseMonitor(Configuration) - Constructor for class org.apache.hadoop.hbase.util.JvmPauseMonitor
- JvmPauseMonitor(Configuration, JvmPauseMonitorSource) - Constructor for class org.apache.hadoop.hbase.util.JvmPauseMonitor
- org.apache.hadoop.hbase.metrics.JvmPauseMonitorSource - Interface in org.apache.hadoop.hbase.metrics
-
Interface for sources that will export JvmPauseMonitor metrics
- org.apache.hadoop.hbase.util.JvmVersion - Class in org.apache.hadoop.hbase.util
-
Utility class to get and check the current JVM version.
- JvmVersion() - Constructor for class org.apache.hadoop.hbase.util.JvmVersion
K
- K - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
ASCII code for 'K'
- KB_IN_BYTES - Static variable in class org.apache.hadoop.hbase.HConstants
-
KB, MB, GB, TB equivalent to how many bytes
- KEEP_ALIVE_SEC_OPTION - Static variable in class org.apache.hadoop.hbase.thrift.Constants
- KEEP_DELETED_CELLS - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
Retain all cells across flushes and compactions even if they fall behind a delete tombstone.
- KEEP_SEQID_PERIOD - Static variable in class org.apache.hadoop.hbase.HConstants
-
Parameter name for # days to keep MVCC values during a major compaction
- KEEPALIVE_MILLIS - Static variable in class org.apache.hadoop.hbase.zookeeper.ReadOnlyZKClient
- keepDeletedCells - Variable in class org.apache.hadoop.hbase.regionserver.querymatcher.CompactionScanQueryMatcher
-
whether to return deleted rows
- org.apache.hadoop.hbase.KeepDeletedCells - Enum Class in org.apache.hadoop.hbase
-
Ways to keep cells marked for delete around.
- keeperException(KeeperException) - Method in class org.apache.hadoop.hbase.zookeeper.ZKWatcher
-
Handles KeeperExceptions in client calls.
- KERBEROS - Enum constant in enum class org.apache.hadoop.hbase.security.AuthMethod
- org.apache.hadoop.hbase.util.KerberosUtils - Class in org.apache.hadoop.hbase.util
- KerberosUtils() - Constructor for class org.apache.hadoop.hbase.util.KerberosUtils
- KEY_ENCODING_QUERY_PARAM_NAME - Static variable in interface org.apache.hadoop.hbase.rest.Constants
- KEY_FOR_HOSTNAME_SEEN_BY_MASTER - Static variable in class org.apache.hadoop.hbase.HConstants
- KEY_INFRASTRUCTURE_SIZE - Static variable in class org.apache.hadoop.hbase.KeyValue
- KEY_LENGTH - Static variable in class org.apache.hadoop.hbase.io.crypto.Cipher
- KEY_LENGTH_BITS - Static variable in class org.apache.hadoop.hbase.io.crypto.Cipher
- KEY_LENGTH_SIZE - Static variable in class org.apache.hadoop.hbase.KeyValue
-
Size of the key length field in bytes
- KEY_MAX_REGIONS - Static variable in class org.apache.hadoop.hbase.master.TableNamespaceManager
- KEY_MAX_TABLES - Static variable in class org.apache.hadoop.hbase.master.TableNamespaceManager
- KEY_VALUE_LEN_SIZE - Static variable in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
-
The size of a (key length, value length) tuple that prefixes each entry in a data block.
- KEY_VALUE_VER_WITH_MEMSTORE - Static variable in class org.apache.hadoop.hbase.io.hfile.HFileWriterImpl
-
Version for KeyValue which includes memstore timestamp
- KEY_VALUE_VERSION - Static variable in class org.apache.hadoop.hbase.io.hfile.HFileWriterImpl
-
KeyValue version in FileInfo
- KEY_WORD_TRUNCATED - Static variable in class org.apache.hadoop.hbase.ipc.RpcServer
- keyCount - Variable in class org.apache.hadoop.hbase.util.BloomFilterChunk
-
Keys currently in the bloom
- keyLength(Cell) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
-
Returns number of bytes this cell's key part would have been used if serialized as in
KeyValue
. - org.apache.hadoop.hbase.util.KeyLocker<K> - Class in org.apache.hadoop.hbase.util
-
A utility class to manage a set of locks.
- KeyLocker() - Constructor for class org.apache.hadoop.hbase.util.KeyLocker
- org.apache.hadoop.hbase.exceptions.KeyManagerException - Exception in org.apache.hadoop.hbase.exceptions
- KeyManagerException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.KeyManagerException
- KeyManagerException(Throwable) - Constructor for exception org.apache.hadoop.hbase.exceptions.KeyManagerException
- keyOfBiggestCell - Variable in class org.apache.hadoop.hbase.io.hfile.HFileWriterImpl
-
Key of the biggest cell.
- keyOnly(byte[]) - Static method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- org.apache.hadoop.hbase.filter.KeyOnlyFilter - Class in org.apache.hadoop.hbase.filter
-
A filter that will only return the key component of each KV (the value will be rewritten as empty).
- KeyOnlyFilter() - Constructor for class org.apache.hadoop.hbase.filter.KeyOnlyFilter
- KeyOnlyFilter(boolean) - Constructor for class org.apache.hadoop.hbase.filter.KeyOnlyFilter
- KeyOnlyKeyValue() - Constructor for class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
- KeyOnlyKeyValue(byte[]) - Constructor for class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
- KeyOnlyKeyValue(byte[], int, int) - Constructor for class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
- keyPassword(String) - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
- org.apache.hadoop.hbase.regionserver.KeyPrefixRegionSplitPolicy - Class in org.apache.hadoop.hbase.regionserver
-
Deprecated.since 3.0.0 and will be removed in 4.0.0. Use
RegionSplitRestriction
, instead. - KeyPrefixRegionSplitPolicy() - Constructor for class org.apache.hadoop.hbase.regionserver.KeyPrefixRegionSplitPolicy
-
Deprecated.
- org.apache.hadoop.hbase.regionserver.KeyPrefixRegionSplitRestriction - Class in org.apache.hadoop.hbase.regionserver
-
A
RegionSplitRestriction
implementation that groups rows by a prefix of the row-key. - KeyPrefixRegionSplitRestriction() - Constructor for class org.apache.hadoop.hbase.regionserver.KeyPrefixRegionSplitRestriction
- org.apache.hadoop.hbase.hbtop.terminal.KeyPress - Class in org.apache.hadoop.hbase.hbtop.terminal
-
Represents the user pressing a key on the keyboard.
- KeyPress(KeyPress.Type, Character, boolean, boolean, boolean) - Constructor for class org.apache.hadoop.hbase.hbtop.terminal.KeyPress
- org.apache.hadoop.hbase.hbtop.terminal.KeyPress.Type - Enum Class in org.apache.hadoop.hbase.hbtop.terminal
- org.apache.hadoop.hbase.hbtop.terminal.impl.KeyPressGenerator - Class in org.apache.hadoop.hbase.hbtop.terminal.impl
-
This generates
KeyPress
objects from the given input stream and offers them to the given queue. - KeyPressGenerator(InputStream, Queue<KeyPress>) - Constructor for class org.apache.hadoop.hbase.hbtop.terminal.impl.KeyPressGenerator
- org.apache.hadoop.hbase.io.crypto.KeyProvider - Interface in org.apache.hadoop.hbase.io.crypto
-
KeyProvider is a interface to abstract the different methods of retrieving key material from key storage such as Java key store.
- org.apache.hadoop.hbase.util.KeyRange - Interface in org.apache.hadoop.hbase.util
-
A key range use in split coverage.
- KEYS - Static variable in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- KEYS_FOR_HBA_CREATE_TABLE - Static variable in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- keySet() - Method in class org.apache.hadoop.hbase.hbtop.Record
- keySet() - Method in class org.apache.hadoop.hbase.io.hfile.HFileInfo
- keySet() - Method in class org.apache.hadoop.hbase.regionserver.CellFlatMap
- keySet() - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
- keySize() - Method in class org.apache.hadoop.hbase.regionserver.AbstractMemStore
-
Returns The total size of cells in this memstore.
- keySize() - Method in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
- keySize() - Method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore
- keyStore(String, String, String) - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
- org.apache.hadoop.hbase.io.crypto.tls.KeyStoreFileType - Enum Class in org.apache.hadoop.hbase.io.crypto.tls
-
This enum represents the file type of a KeyStore or TrustStore.
- org.apache.hadoop.hbase.io.crypto.KeyStoreKeyProvider - Class in org.apache.hadoop.hbase.io.crypto
-
A basic KeyProvider that can resolve keys from a protected KeyStore file on the local filesystem.
- KeyStoreKeyProvider() - Constructor for class org.apache.hadoop.hbase.io.crypto.KeyStoreKeyProvider
- keyTab - Static variable in class org.apache.hadoop.hbase.thrift.HttpDoAsClient
- keyToString(byte[]) - Static method in class org.apache.hadoop.hbase.KeyValue
-
Return key as a String, empty string if k is null.
- keyToString(byte[], int, int) - Static method in class org.apache.hadoop.hbase.KeyValue
-
Use for logging.
- org.apache.hadoop.hbase.KeyValue - Class in org.apache.hadoop.hbase
-
An HBase Key/Value.
- KeyValue() - Constructor for class org.apache.hadoop.hbase.KeyValue
-
Writable Constructor -- DO NOT USE
- KeyValue(byte[]) - Constructor for class org.apache.hadoop.hbase.KeyValue
-
Creates a KeyValue from the start of the specified byte array.
- KeyValue(byte[], byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.KeyValue
-
Constructs KeyValue structure filled with null value.
- KeyValue(byte[], byte[], byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.KeyValue
-
Constructs KeyValue structure as a put filled with specified values and LATEST_TIMESTAMP.
- KeyValue(byte[], byte[], byte[], int, int, long, KeyValue.Type, byte[], int, int, byte[]) - Constructor for class org.apache.hadoop.hbase.KeyValue
- KeyValue(byte[], byte[], byte[], int, int, long, KeyValue.Type, byte[], int, int, List<Tag>) - Constructor for class org.apache.hadoop.hbase.KeyValue
-
Constructs KeyValue structure filled with specified values.
- KeyValue(byte[], byte[], byte[], long, byte[]) - Constructor for class org.apache.hadoop.hbase.KeyValue
-
Constructs KeyValue structure filled with specified values.
- KeyValue(byte[], byte[], byte[], long, byte[], List<Tag>) - Constructor for class org.apache.hadoop.hbase.KeyValue
-
Constructs KeyValue structure filled with specified values.
- KeyValue(byte[], byte[], byte[], long, byte[], Tag[]) - Constructor for class org.apache.hadoop.hbase.KeyValue
-
Constructs KeyValue structure filled with specified values.
- KeyValue(byte[], byte[], byte[], long, KeyValue.Type) - Constructor for class org.apache.hadoop.hbase.KeyValue
-
Constructs KeyValue structure filled with specified values.
- KeyValue(byte[], byte[], byte[], long, KeyValue.Type, byte[]) - Constructor for class org.apache.hadoop.hbase.KeyValue
-
Constructs KeyValue structure filled with specified values.
- KeyValue(byte[], byte[], byte[], long, KeyValue.Type, byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.KeyValue
-
Constructs KeyValue structure filled with specified values.
- KeyValue(byte[], byte[], byte[], long, KeyValue.Type, byte[], List<Tag>) - Constructor for class org.apache.hadoop.hbase.KeyValue
-
Constructs KeyValue structure filled with specified values.
- KeyValue(byte[], int) - Constructor for class org.apache.hadoop.hbase.KeyValue
-
Creates a KeyValue from the specified byte array and offset.
- KeyValue(byte[], int, byte[], int, int, byte[], int, int, byte[], int, int, long, KeyValue.Type, byte[], int, int, Tag[]) - Constructor for class org.apache.hadoop.hbase.KeyValue
-
Constructs KeyValue structure filled with specified values.
- KeyValue(byte[], int, int) - Constructor for class org.apache.hadoop.hbase.KeyValue
-
Creates a KeyValue from the specified byte array, starting at offset, and for length
length
. - KeyValue(byte[], int, int, byte[], int, int, byte[], int, int, long, KeyValue.Type, byte[], int, int) - Constructor for class org.apache.hadoop.hbase.KeyValue
-
Constructs KeyValue structure filled with specified values.
- KeyValue(byte[], int, int, byte[], int, int, byte[], int, int, long, KeyValue.Type, byte[], int, int, byte[], int, int) - Constructor for class org.apache.hadoop.hbase.KeyValue
- KeyValue(byte[], int, int, byte[], int, int, byte[], int, int, long, KeyValue.Type, byte[], int, int, List<Tag>) - Constructor for class org.apache.hadoop.hbase.KeyValue
-
Constructs KeyValue structure filled with specified values.
- KeyValue(byte[], int, int, byte[], int, int, ByteBuffer, long, KeyValue.Type, ByteBuffer, List<Tag>) - Constructor for class org.apache.hadoop.hbase.KeyValue
- KeyValue(byte[], int, int, long) - Constructor for class org.apache.hadoop.hbase.KeyValue
-
Creates a KeyValue from the specified byte array, starting at offset, and for length
length
. - KeyValue(byte[], long) - Constructor for class org.apache.hadoop.hbase.KeyValue
-
Constructs KeyValue structure filled with null value.
- KeyValue(byte[], long, KeyValue.Type) - Constructor for class org.apache.hadoop.hbase.KeyValue
-
Constructs KeyValue structure filled with null value.
- KeyValue(int, int, int, long, KeyValue.Type, int) - Constructor for class org.apache.hadoop.hbase.KeyValue
-
Constructs an empty KeyValue structure, with specified sizes.
- KeyValue(int, int, int, long, KeyValue.Type, int, int) - Constructor for class org.apache.hadoop.hbase.KeyValue
-
Constructs an empty KeyValue structure, with specified sizes.
- KeyValue(ExtendedCell) - Constructor for class org.apache.hadoop.hbase.KeyValue
- KEYVALUE_INFRASTRUCTURE_SIZE - Static variable in class org.apache.hadoop.hbase.KeyValue
- KEYVALUE_WITH_TAGS_INFRASTRUCTURE_SIZE - Static variable in class org.apache.hadoop.hbase.KeyValue
- org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue - Class in org.apache.hadoop.hbase
-
A simple form of KeyValue that creates a keyvalue with only the key part of the byte[] Mainly used in places where we need to compare two cells.
- org.apache.hadoop.hbase.KeyValue.SamePrefixComparator<T> - Interface in org.apache.hadoop.hbase
-
Avoids redundant comparisons for better performance.
- org.apache.hadoop.hbase.KeyValue.Type - Enum Class in org.apache.hadoop.hbase
-
Key type.
- org.apache.hadoop.hbase.codec.KeyValueCodec - Class in org.apache.hadoop.hbase.codec
-
Codec that does KeyValue version 1 serialization.
- KeyValueCodec() - Constructor for class org.apache.hadoop.hbase.codec.KeyValueCodec
- org.apache.hadoop.hbase.codec.KeyValueCodec.ByteBuffKeyValueDecoder - Class in org.apache.hadoop.hbase.codec
- org.apache.hadoop.hbase.codec.KeyValueCodec.KeyValueDecoder - Class in org.apache.hadoop.hbase.codec
- org.apache.hadoop.hbase.codec.KeyValueCodec.KeyValueEncoder - Class in org.apache.hadoop.hbase.codec
- org.apache.hadoop.hbase.codec.KeyValueCodecWithTags - Class in org.apache.hadoop.hbase.codec
-
Codec that does KeyValue version 1 serialization with serializing tags also.
- KeyValueCodecWithTags() - Constructor for class org.apache.hadoop.hbase.codec.KeyValueCodecWithTags
- org.apache.hadoop.hbase.codec.KeyValueCodecWithTags.ByteBuffKeyValueDecoder - Class in org.apache.hadoop.hbase.codec
- org.apache.hadoop.hbase.codec.KeyValueCodecWithTags.KeyValueDecoder - Class in org.apache.hadoop.hbase.codec
- org.apache.hadoop.hbase.codec.KeyValueCodecWithTags.KeyValueEncoder - Class in org.apache.hadoop.hbase.codec
- KeyValueDecoder(InputStream) - Constructor for class org.apache.hadoop.hbase.codec.KeyValueCodec.KeyValueDecoder
- KeyValueDecoder(InputStream) - Constructor for class org.apache.hadoop.hbase.codec.KeyValueCodecWithTags.KeyValueDecoder
- KeyValueEncoder(OutputStream) - Constructor for class org.apache.hadoop.hbase.codec.KeyValueCodec.KeyValueEncoder
- KeyValueEncoder(OutputStream) - Constructor for class org.apache.hadoop.hbase.codec.KeyValueCodecWithTags.KeyValueEncoder
- org.apache.hadoop.hbase.regionserver.KeyValueHeap - Class in org.apache.hadoop.hbase.regionserver
-
Implements a heap merge across any number of KeyValueScanners.
- KeyValueHeap(List<? extends KeyValueScanner>, CellComparator) - Constructor for class org.apache.hadoop.hbase.regionserver.KeyValueHeap
-
Constructor.
- org.apache.hadoop.hbase.regionserver.KeyValueHeap.KVScannerComparator - Class in org.apache.hadoop.hbase.regionserver
- org.apache.hadoop.hbase.regionserver.KeyValueScanner - Interface in org.apache.hadoop.hbase.regionserver
-
Scanner that returns the next KeyValue.
- org.apache.hadoop.hbase.KeyValueTestUtil - Class in org.apache.hadoop.hbase
- KeyValueTestUtil() - Constructor for class org.apache.hadoop.hbase.KeyValueTestUtil
- org.apache.hadoop.hbase.KeyValueUtil - Class in org.apache.hadoop.hbase
-
static convenience methods for dealing with KeyValues and collections of KeyValues
- KeyValueUtil() - Constructor for class org.apache.hadoop.hbase.KeyValueUtil
- kill() - Method in class org.apache.hadoop.hbase.MiniHBaseCluster.MiniHBaseClusterRegionServer
-
Deprecated.
- kill() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
- killAll() - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.Do a simulated kill all masters and regionservers.
- killCurrentActiveZooKeeperServer() - Method in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
- killDataNode(ServerName) - Method in class org.apache.hadoop.hbase.HBaseCluster
-
Deprecated.Kills the datanode process if this is a distributed cluster, otherwise, this causes master to exit doing basic clean up only.
- killDataNode(ServerName) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.
- killMaster(ServerName) - Method in class org.apache.hadoop.hbase.HBaseCluster
-
Deprecated.Kills the master process if this is a distributed cluster, otherwise, this causes master to exit doing basic clean up only.
- killMaster(ServerName) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.
- killMiniHBaseCluster() - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Abruptly Shutdown HBase mini cluster.
- killNameNode(ServerName) - Method in class org.apache.hadoop.hbase.HBaseCluster
-
Deprecated.Kills the namenode process if this is a distributed cluster, otherwise, this causes master to exit doing basic clean up only.
- killNameNode(ServerName) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.
- killOneBackupZooKeeperServer() - Method in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
-
Kill one back up ZK servers.
- killRegionServer(ServerName) - Method in class org.apache.hadoop.hbase.HBaseCluster
-
Deprecated.Kills the region server process if this is a distributed cluster, otherwise this causes the region server to exit doing basic clean up only.
- killRegionServer(ServerName) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.
- killZkNode(ServerName) - Method in class org.apache.hadoop.hbase.HBaseCluster
-
Deprecated.Kills the zookeeper node process if this is a distributed cluster, otherwise, this causes master to exit doing basic clean up only.
- killZkNode(ServerName) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.
- KILOBYTE - Enum constant in enum class org.apache.hadoop.hbase.Size.Unit
- kvComparator - Variable in class org.apache.hadoop.hbase.regionserver.KeyValueHeap.KVScannerComparator
- kvCreator - Variable in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
- KVP_DELIMITER - Static variable in class org.apache.hadoop.hbase.util.ConfigurationUtil
- KVScannerComparator(CellComparator) - Constructor for class org.apache.hadoop.hbase.regionserver.KeyValueHeap.KVScannerComparator
-
Constructor
L
- L - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
ASCII code for 'L'
- L1_CACHE_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- L1_CACHE_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- L1_CACHE_EVICTION_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- L1_CACHE_EVICTION_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- L1_CACHE_FREE_SIZE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- L1_CACHE_FREE_SIZE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- L1_CACHE_HIT_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- L1_CACHE_HIT_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- L1_CACHE_HIT_RATIO - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- L1_CACHE_HIT_RATIO_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- L1_CACHE_MISS_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- L1_CACHE_MISS_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- L1_CACHE_MISS_RATIO - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- L1_CACHE_MISS_RATIO_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- L1_CACHE_SIZE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- L1_CACHE_SIZE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- l1Cache - Variable in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
- L2_CACHE_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- L2_CACHE_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- L2_CACHE_EVICTION_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- L2_CACHE_EVICTION_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- L2_CACHE_FREE_SIZE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- L2_CACHE_FREE_SIZE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- L2_CACHE_HIT_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- L2_CACHE_HIT_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- L2_CACHE_HIT_RATIO - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- L2_CACHE_HIT_RATIO_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- L2_CACHE_MISS_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- L2_CACHE_MISS_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- L2_CACHE_MISS_RATIO - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- L2_CACHE_MISS_RATIO_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- L2_CACHE_SIZE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- L2_CACHE_SIZE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- l2Cache - Variable in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
- label - Variable in class org.apache.hadoop.hbase.util.MovingAverage
- LARGE_COMPACTION_QUEUE_LENGTH - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- LARGE_COMPACTION_QUEUE_LENGTH_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- LARGE_COMPACTION_THREADS - Static variable in class org.apache.hadoop.hbase.regionserver.CompactSplit
- LARGE_COMPACTION_THREADS_DEFAULT - Static variable in class org.apache.hadoop.hbase.regionserver.CompactSplit
- LARGE_LOG - Enum constant in enum class org.apache.hadoop.hbase.client.LogQueryFilter.Type
-
Deprecated.
- last() - Method in class org.apache.hadoop.hbase.regionserver.CellSet
- last() - Method in class org.apache.hadoop.hbase.regionserver.CompositeImmutableSegment
- last() - Method in class org.apache.hadoop.hbase.regionserver.Segment
- LAST_BLOOM_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.HStoreFile
-
Last Bloom filter key in FileInfo
- LAST_CHAR - Static variable in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- LAST_MAJOR_COMPACTION_AGE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
- LAST_MAJOR_COMPACTION_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
- LAST_MAJOR_COMPACTION_TIME - Enum constant in enum class org.apache.hadoop.hbase.hbtop.field.Field
- LAST_REGION_ENDKEY_NOT_EMPTY - Enum constant in enum class org.apache.hadoop.hbase.util.HbckErrorReporter.ERROR_CODE
-
Deprecated.
- LAST_ROW - Static variable in class org.apache.hadoop.hbase.HConstants
-
Used by scanners and others when they're trying to detect the end of a table
- LAST_SEQUENCE_ID_FAMILY - Static variable in class org.apache.hadoop.hbase.replication.TableReplicationQueueStorage
- last_update - Variable in class org.apache.hadoop.hbase.master.SplitLogManager.Task
-
Deprecated.
- last_version - Variable in class org.apache.hadoop.hbase.master.SplitLogManager.Task
-
Deprecated.
- lastCell - Variable in class org.apache.hadoop.hbase.io.hfile.HFileWriterImpl
-
The Cell previously appended.
- lastDataBlockOffset - Variable in class org.apache.hadoop.hbase.io.hfile.HFileWriterImpl
-
The offset of the last data block or 0 if the file is empty.
- lastEntry() - Method in class org.apache.hadoop.hbase.regionserver.CellFlatMap
- lastEntry() - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
- lastFlushedSequenceIds - Variable in class org.apache.hadoop.hbase.wal.WALSplitter
- lastHost - Variable in class org.apache.hadoop.hbase.rest.client.Cluster
- lastIndexOf(Object) - Method in class org.apache.hadoop.hbase.util.SortedList
- lastKey() - Method in class org.apache.hadoop.hbase.io.hfile.HFileInfo
- lastKey() - Method in class org.apache.hadoop.hbase.regionserver.CellFlatMap
- lastKey() - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
- lastN - Variable in class org.apache.hadoop.hbase.util.WindowMovingAverage
- lastQuery - Variable in class org.apache.hadoop.hbase.quotas.QuotaState
- lastReplayedCompactionSeqId - Variable in class org.apache.hadoop.hbase.regionserver.HRegion
- lastReplayedOpenRegionSeqId - Variable in class org.apache.hadoop.hbase.regionserver.HRegion
-
The sequence id of the last replayed open region event from the primary region.
- lastRow() - Method in class org.apache.hadoop.hbase.util.RegionSplitter.NumberStringSplit
- lastRow() - Method in interface org.apache.hadoop.hbase.util.RegionSplitter.SplitAlgorithm
-
In HBase, the last row is represented by an empty byte array.
- lastRow() - Method in class org.apache.hadoop.hbase.util.RegionSplitter.UniformSplit
- lastRowInCurrentWriter - Variable in class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter.SizeMultiWriter
- org.apache.hadoop.hbase.regionserver.LastSequenceId - Interface in org.apache.hadoop.hbase.regionserver
-
Last flushed sequence Ids for the regions and their stores on region server
- lastUpdate - Variable in class org.apache.hadoop.hbase.quotas.QuotaState
- LATEST_TIMESTAMP - Static variable in class org.apache.hadoop.hbase.HConstants
-
Timestamp to use when we want to refer to the latest cell.
- LATEST_TIMESTAMP_BYTES - Static variable in class org.apache.hadoop.hbase.HConstants
-
LATEST_TIMESTAMP in bytes form
- LATEST_TS - Static variable in class org.apache.hadoop.hbase.util.CellHashKey
- latestVersionOnly - Variable in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
- LEAF_INDEX - Enum constant in enum class org.apache.hadoop.hbase.io.hfile.BlockType
-
Version 2 leaf index block.
- LEASE_RECOVERABLE_CLASS_NAME - Static variable in class org.apache.hadoop.hbase.util.RecoverLeaseFSUtils
- org.apache.hadoop.hbase.regionserver.LeaseException - Exception in org.apache.hadoop.hbase.regionserver
-
Reports a problem with a lease
- LeaseException() - Constructor for exception org.apache.hadoop.hbase.regionserver.LeaseException
-
default constructor
- LeaseException(String) - Constructor for exception org.apache.hadoop.hbase.regionserver.LeaseException
- leaseExpired() - Method in interface org.apache.hadoop.hbase.regionserver.LeaseListener
-
When a lease expires, this method is called.
- org.apache.hadoop.hbase.regionserver.LeaseListener - Interface in org.apache.hadoop.hbase.regionserver
-
LeaseListener is an interface meant to be implemented by users of the Leases class.
- org.apache.hadoop.hbase.regionserver.LeaseManager - Class in org.apache.hadoop.hbase.regionserver
-
Leases There are several server classes in HBase that need to track external clients that occasionally send heartbeats.
- LeaseManager(int) - Constructor for class org.apache.hadoop.hbase.regionserver.LeaseManager
-
Creates a lease manager.
- org.apache.hadoop.hbase.regionserver.LeaseManager.LeaseStillHeldException - Exception in org.apache.hadoop.hbase.regionserver
-
Thrown if we are asked to create a lease but lease on passed name already exists.
- org.apache.hadoop.hbase.util.LeaseNotRecoveredException - Exception in org.apache.hadoop.hbase.util
-
Thrown when the lease was expected to be recovered, but the file can't be opened.
- LeaseNotRecoveredException() - Constructor for exception org.apache.hadoop.hbase.util.LeaseNotRecoveredException
- LeaseNotRecoveredException(String) - Constructor for exception org.apache.hadoop.hbase.util.LeaseNotRecoveredException
- LeaseNotRecoveredException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.util.LeaseNotRecoveredException
- LeaseNotRecoveredException(Throwable) - Constructor for exception org.apache.hadoop.hbase.util.LeaseNotRecoveredException
- LeaseStillHeldException(String) - Constructor for exception org.apache.hadoop.hbase.regionserver.LeaseManager.LeaseStillHeldException
- LEGACY_REGION_REPLICATION_ENDPOINT_NAME - Static variable in class org.apache.hadoop.hbase.replication.ReplicationUtils
- len(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Returns length of the byte array, returning 0 if the array is null.
- length - Variable in class org.apache.hadoop.hbase.ByteBufferKeyValue
- length - Variable in class org.apache.hadoop.hbase.KeyValue
- length - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractProtobufLogWriter
- length - Variable in class org.apache.hadoop.hbase.types.FixedLengthWrapper
- length - Variable in class org.apache.hadoop.hbase.util.AbstractByteRange
-
The number of bytes in the range.
- length() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
- length() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
- length() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileReader
- length() - Method in class org.apache.hadoop.hbase.util.ByteArrayHashKey
- length() - Method in class org.apache.hadoop.hbase.util.HashKey
-
Returns The number of bytes in this HashKey
- length() - Method in class org.apache.hadoop.hbase.util.RowBloomHashKey
- length() - Method in class org.apache.hadoop.hbase.util.RowColBloomHashKey
- length(short, byte, int, int, int, boolean) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
-
length
- length(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Return the number of encoded entries remaining in
buff
. - lengthOfPBMagic() - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Returns Length of
ProtobufMagic.lengthOfPBMagic()
- lengthWithMvccVersion(KeyValue, boolean) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
- lenOfBiggestCell - Variable in class org.apache.hadoop.hbase.io.hfile.HFileWriterImpl
-
Len of the biggest cell.
- less(Object) - Method in class org.apache.hadoop.hbase.hbtop.RecordFilter.FilterBuilder
- less(FieldValue) - Method in class org.apache.hadoop.hbase.hbtop.RecordFilter.FilterBuilder
- LESS - Enum constant in enum class org.apache.hadoop.hbase.CompareOperator
-
less than
- LESS_OR_EQUAL - Enum constant in enum class org.apache.hadoop.hbase.CompareOperator
-
less than or equal to
- LESS_THAN_ARRAY - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
LESS_THAN Array
- LESS_THAN_BUFFER - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
- LESS_THAN_OR_EQUAL_TO_ARRAY - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
LESS_THAN_OR_EQUAL_TO Array
- LESS_THAN_OR_EQUAL_TO_BUFFER - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
- lessOrEqual(Object) - Method in class org.apache.hadoop.hbase.hbtop.RecordFilter.FilterBuilder
- lessOrEqual(FieldValue) - Method in class org.apache.hadoop.hbase.hbtop.RecordFilter.FilterBuilder
- limit - Variable in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
- limit() - Method in class org.apache.hadoop.hbase.nio.ByteBuff
-
Returns the limit of this ByteBuff
- limit() - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
Returns the limit of this MBB
- limit() - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
- limit(int) - Method in class org.apache.hadoop.hbase.nio.ByteBuff
-
Marks the limit of this ByteBuff
- limit(int) - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
Marks the limit of this MBB.
- limit(int) - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
- limiters - Variable in class org.apache.hadoop.hbase.quotas.DefaultOperationQuota
- limitNamespaceSpace(String, long, SpaceViolationPolicy) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
-
Creates a
QuotaSettings
object to limit the FileSystem space usage for the given namespace to the given size in bytes. - limitNumMapTasks(String, JobConf) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
-
Ensures that the given number of map tasks for the given job configuration does not exceed the number of regions for the given table.
- limitNumReduceTasks(String, JobConf) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
-
Ensures that the given number of reduce tasks for the given job configuration does not exceed the number of regions for the given table.
- limitNumReduceTasks(String, Job) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Ensures that the given number of reduce tasks for the given job configuration does not exceed the number of regions for the given table.
- limitReached() - Method in enum class org.apache.hadoop.hbase.regionserver.ScannerContext.NextState
-
Returns true when the state indicates that a limit has been reached and scan should stop
- limitTableSpace(TableName, long, SpaceViolationPolicy) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
-
Creates a
QuotaSettings
object to limit the FileSystem space usage for the given table to the given size in bytes. - LINGERING_HFILELINK - Enum constant in enum class org.apache.hadoop.hbase.util.HbckErrorReporter.ERROR_CODE
-
Deprecated.
- LINGERING_REFERENCE_HFILE - Enum constant in enum class org.apache.hadoop.hbase.util.HbckErrorReporter.ERROR_CODE
-
Deprecated.
- LINGERING_SPLIT_PARENT - Enum constant in enum class org.apache.hadoop.hbase.util.HbckErrorReporter.ERROR_CODE
-
Deprecated.
- LINK_NAME_PATTERN - Static variable in class org.apache.hadoop.hbase.io.HFileLink
-
Define the HFile Link name parser in the form of: table=region-hfile
- LINK_NAME_REGEX - Static variable in class org.apache.hadoop.hbase.io.HFileLink
-
A non-capture group, for HFileLink, so that this can be embedded.
- LINKEDLIST - Static variable in class org.apache.hadoop.hbase.util.ClassSize
-
Overhead for LinkedList(0)
- LINKEDLIST_ENTRY - Static variable in class org.apache.hadoop.hbase.util.ClassSize
-
Overhead for a single entry in LinkedList
- linkToWriter(MultiThreadedWriterBase) - Method in class org.apache.hadoop.hbase.util.MultiThreadedReader
- linkToWriter(MultiThreadedWriterBase) - Method in class org.apache.hadoop.hbase.util.MultiThreadedUpdater
- list() - Method in class org.apache.hadoop.hbase.master.TableNamespaceManager
- list(String) - Method in class org.apache.hadoop.hbase.zookeeper.ReadOnlyZKClient
- list(String, long) - Method in class org.apache.hadoop.hbase.zookeeper.ReadOnlyZKClient
- listAllFilesNames(Map<String, HRegion>) - Static method in class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil
- listAllHFileRefs() - Method in class org.apache.hadoop.hbase.replication.ZKReplicationQueueStorageForMigration
-
Pair<PeerId, List<HFileRefs>>
- listAllLastPushedSeqIds() - Method in class org.apache.hadoop.hbase.replication.ZKReplicationQueueStorageForMigration
- listAllQueueIds(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueueStorage
-
Get a list of all queues for the specific peer.
- listAllQueueIds(String) - Method in class org.apache.hadoop.hbase.replication.TableReplicationQueueStorage
- listAllQueueIds(String, ServerName) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueueStorage
-
Get a list of all queues for the specific region server and the specific peer
- listAllQueueIds(String, ServerName) - Method in class org.apache.hadoop.hbase.replication.TableReplicationQueueStorage
- listAllQueueIds(ServerName) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueueStorage
-
Get a list of all queues for the specific region server.
- listAllQueueIds(ServerName) - Method in class org.apache.hadoop.hbase.replication.TableReplicationQueueStorage
- listAllQueues() - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueueStorage
-
Get a list of all queues and the offsets.
- listAllQueues() - Method in class org.apache.hadoop.hbase.replication.TableReplicationQueueStorage
- listAllQueues() - Method in class org.apache.hadoop.hbase.replication.ZKReplicationQueueStorageForMigration
- listAllReplicators() - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueueStorage
-
Get a list of all region servers that have outstanding replication queues.
- listAllReplicators() - Method in class org.apache.hadoop.hbase.replication.TableReplicationQueueStorage
- listBackupSets() - Method in interface org.apache.hadoop.hbase.backup.BackupAdmin
-
Backup sets list command - list all backup sets.
- listCells() - Method in class org.apache.hadoop.hbase.client.Result
-
Create a sorted list of the Cell's in this result.
- listChildrenAndWatchForNewChildren(ZKWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Lists the children znodes of the specified znode.
- listChildrenAndWatchThem(ZKWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
List all the children of the specified znode, setting a watch for children changes and also setting a watch on every individual child in order to get the NodeCreated and NodeDeleted events.
- listChildrenNoWatch(ZKWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Lists the children of the specified znode without setting any watches.
- listDeadServers() - Method in interface org.apache.hadoop.hbase.client.Admin
-
List dead region servers.
- listDeadServers() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
List all the dead region servers.
- listDecommissionedRegionServers() - Method in interface org.apache.hadoop.hbase.client.Admin
-
List region servers marked as decommissioned, which can not be assigned regions.
- listDecommissionedRegionServers() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
List region servers marked as decommissioned, which can not be assigned regions.
- listDecommissionedRegionServers() - Method in class org.apache.hadoop.hbase.master.HMaster
-
List region servers marked as decommissioned (previously called 'draining') to not get regions assigned to them.
- listDecommissionedRegionServers(RpcController, MasterProtos.ListDecommissionedRegionServersRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- listener(BufferedMutator.ExceptionListener) - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
-
Override the default error handler.
- listeners - Variable in class org.apache.hadoop.hbase.errorhandling.ForeignExceptionDispatcher
- listeners - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
Listeners that are called on WAL events.
- listeners - Variable in class org.apache.hadoop.hbase.wal.AbstractWALProvider
- listenPort - Variable in class org.apache.hadoop.hbase.thrift.ThriftServer
- listIterator() - Method in class org.apache.hadoop.hbase.util.SortedList
- listIterator(int) - Method in class org.apache.hadoop.hbase.util.SortedList
- listLocatedStatus(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.CommonFSUtils
-
Calls fs.listFiles() to get FileStatus and BlockLocations together for reducing rpc call
- listNamespaceDescriptors() - Method in interface org.apache.hadoop.hbase.client.Admin
-
List available namespace descriptors
- listNamespaceDescriptors() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
List available namespace descriptors
- listNamespaceDescriptors(RpcController, MasterProtos.ListNamespaceDescriptorsRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- listNamespaces() - Method in interface org.apache.hadoop.hbase.client.Admin
-
List available namespaces
- listNamespaces() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
List available namespaces
- listNamespaces() - Method in class org.apache.hadoop.hbase.master.HMaster
-
List namespace names
- listNamespaces(RpcController, MasterProtos.ListNamespacesRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- listPeerIds() - Method in class org.apache.hadoop.hbase.replication.FSReplicationPeerStorage
- listPeerIds() - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeerStorage
-
Return the peer ids of all replication peers.
- listPeerIds() - Method in class org.apache.hadoop.hbase.replication.ZKReplicationPeerStorage
- listReplicatedTableCFs() - Method in interface org.apache.hadoop.hbase.client.Admin
-
Find all table and column families that are replicated from this cluster
- listReplicatedTableCFs() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Find all table and column families that are replicated from this cluster
- listReplicationPeers() - Method in interface org.apache.hadoop.hbase.client.Admin
-
Return a list of replication peers.
- listReplicationPeers() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Return a list of replication peers.
- listReplicationPeers(String) - Method in class org.apache.hadoop.hbase.master.HMaster
- listReplicationPeers(String) - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Return a list of replication peers.
- listReplicationPeers(Pattern) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Return a list of replication peers.
- listReplicationPeers(Pattern) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Return a list of replication peers.
- listReplicationPeers(RpcController, ReplicationProtos.ListReplicationPeersRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- listRSGroupInfos(RpcController, RSGroupAdminProtos.ListRSGroupInfosRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- listRSGroups() - Method in interface org.apache.hadoop.hbase.client.Admin
-
Lists current set of RegionServer groups
- listRSGroups() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Lists current set of RegionServer groups
- listRSGroups() - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminClient
-
Deprecated.Lists current set of RegionServer groups.
- listRSGroups() - Method in interface org.apache.hadoop.hbase.rsgroup.RSGroupInfoManager
-
List the existing
RSGroupInfo
s. - listSnapshots() - Method in interface org.apache.hadoop.hbase.client.Admin
-
List completed snapshots.
- listSnapshots() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
List completed snapshots.
- listSnapshots(Pattern) - Method in interface org.apache.hadoop.hbase.client.Admin
-
List all the completed snapshots matching the given pattern.
- listSnapshots(Pattern) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
List all the completed snapshots matching the given pattern.
- listStatus(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.CommonFSUtils
-
Calls fs.listStatus() and treats FileNotFoundException as non-fatal This would accommodates differences between hadoop versions
- listStatus(FileSystem, Path, PathFilter) - Static method in class org.apache.hadoop.hbase.util.CommonFSUtils
-
Calls fs.listStatus() and treats FileNotFoundException as non-fatal This accommodates differences between hadoop versions, where hadoop 1 does not throw a FileNotFoundException, and return an empty FileStatus[] while Hadoop 2 will throw FileNotFoundException.
- listStatus(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.HFileInputFormat
- listStatusWithStatusFilter(FileSystem, Path, FileStatusFilter) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Calls fs.listStatus() and treats FileNotFoundException as non-fatal This accommodates differences between hadoop versions, where hadoop 1 does not throw a FileNotFoundException, and return an empty FileStatus[] while Hadoop 2 will throw FileNotFoundException.
- listTableDescriptors() - Method in interface org.apache.hadoop.hbase.client.Admin
-
List all the userspace tables.
- listTableDescriptors() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
List all the userspace tables.
- listTableDescriptors(boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
-
List all userspace tables and whether or not include system tables.
- listTableDescriptors(boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
List all the tables.
- listTableDescriptors(String, String, List<TableName>, boolean) - Method in class org.apache.hadoop.hbase.master.HMaster
-
Returns the list of table descriptors that match the specified request
- listTableDescriptors(List<TableName>) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get tableDescriptors.
- listTableDescriptors(List<TableName>) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
List specific tables including system tables.
- listTableDescriptors(Pattern) - Method in interface org.apache.hadoop.hbase.client.Admin
-
List all the userspace tables that match the given pattern.
- listTableDescriptors(Pattern, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
-
List all the tables matching the given pattern.
- listTableDescriptors(Pattern, boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
List all the tables matching the given pattern.
- listTableDescriptorsByNamespace(byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get list of table descriptors by namespace.
- listTableDescriptorsByNamespace(String) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Get list of table descriptors by namespace.
- listTableDescriptorsByNamespace(String) - Method in class org.apache.hadoop.hbase.master.HMaster
- listTableDescriptorsByNamespace(String) - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Get list of table descriptors by namespace
- listTableDescriptorsByNamespace(RpcController, MasterProtos.ListTableDescriptorsByNamespaceRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- listTableDescriptorsByState(boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
-
List all enabled or disabled tables
- listTableDescriptorsByState(boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
List all enabled or disabled table descriptors
- listTableDescriptorsByState(RpcController, MasterProtos.ListTableDescriptorsByStateRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- listTableNames() - Method in interface org.apache.hadoop.hbase.client.Admin
-
List all of the names of userspace tables.
- listTableNames() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
List all of the names of userspace tables.
- listTableNames(boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
List all of the names of tables.
- listTableNames(String, String, boolean) - Method in class org.apache.hadoop.hbase.master.HMaster
-
Returns the list of table names that match the specified request
- listTableNames(Pattern) - Method in interface org.apache.hadoop.hbase.client.Admin
-
List all of the names of userspace tables.
- listTableNames(Pattern, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
-
List all of the names of userspace tables.
- listTableNames(Pattern, boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
List all of the names of userspace tables.
- listTableNamesByNamespace(String) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get list of table names by namespace.
- listTableNamesByNamespace(String) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Get list of table names by namespace.
- listTableNamesByNamespace(String) - Method in class org.apache.hadoop.hbase.master.HMaster
- listTableNamesByNamespace(String) - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Get list of table names by namespace
- listTableNamesByNamespace(RpcController, MasterProtos.ListTableNamesByNamespaceRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- listTableNamesByState(boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
-
List all enabled or disabled table names
- listTableNamesByState(boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
List all enabled or disabled table names
- listTableNamesByState(RpcController, MasterProtos.ListTableNamesByStateRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- listTablesInRSGroup(String) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get all tables in this RegionServer group.
- listTablesInRSGroup(String) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Get all tables in this RegionServer group.
- listTablesInRSGroup(MasterServices, String) - Static method in class org.apache.hadoop.hbase.rsgroup.RSGroupUtil
- listTablesInRSGroup(RpcController, RSGroupAdminProtos.ListTablesInRSGroupRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- listTableSnapshots(Pattern) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
List all the completed snapshots matching the given table name pattern.
- listTableSnapshots(Pattern, Pattern) - Method in interface org.apache.hadoop.hbase.client.Admin
-
List all the completed snapshots matching the given table name regular expression and snapshot name regular expression.
- listTableSnapshots(Pattern, Pattern) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
List all the completed snapshots matching the given table name regular expression and snapshot name regular expression.
- listUnknownServers() - Method in interface org.apache.hadoop.hbase.client.Admin
-
List unknown region servers.
- listUnknownServers() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
List all the unknown region servers.
- LITTLE_ENDIAN - Static variable in class org.apache.hadoop.hbase.util.UnsafeAccess
- LIVE - Enum constant in enum class org.apache.hadoop.hbase.master.ServerManager.ServerLiveState
- LIVE_REGION_SERVERS_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
- LIVE_REGION_SERVERS_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
- LIVE_SERVERS - Enum constant in enum class org.apache.hadoop.hbase.ClusterMetrics.Option
-
metrics about live region servers
- load() - Static method in class org.apache.hadoop.hbase.metrics.MetricRegistriesLoader
-
Creates a
MetricRegistries
instance using the correspondingMetricRegistries
available toServiceLoader
on the classpath. - load() - Method in interface org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileTracker
-
Load the store files list when opening a region.
- load() - Method in class org.apache.hadoop.hbase.util.RegionMover
-
Loads the specified
RegionMover.hostname
with regions listed in theRegionMover.filename
RegionMover Object has to be created usingRegionMover(RegionMoverBuilder)
- load() - Static method in class org.apache.hadoop.hbase.wal.AsyncFSWALProvider
-
Test whether we can load the helper classes for async dfs output.
- load(Class<? extends C>, int, Configuration) - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
- load(URI) - Method in class org.apache.hadoop.hbase.io.crypto.KeyStoreKeyProvider
- load(Path, String, int, Configuration) - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
-
Load a coprocessor implementation into the host
- load(Path, String, int, Configuration, String[]) - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
-
Load a coprocessor implementation into the host
- LOAD_BALANCE - Enum constant in enum class org.apache.hadoop.hbase.CatalogReplicaMode
- LOAD_BALANCER_SLOP_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
- LOAD_CFS_ON_DEMAND_CONFIG_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.HRegion
- org.apache.hadoop.hbase.master.LoadBalancer - Interface in org.apache.hadoop.hbase.master
-
Makes decisions about the placement and movement of Regions across RegionServers.
- loadBlockAndSeekToKey(HFileBlock, ExtendedCell, boolean, ExtendedCell, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.EncodedScanner
- loadBlockAndSeekToKey(HFileBlock, ExtendedCell, boolean, ExtendedCell, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
- loadBloomfilter(BlockType, BloomFilterMetrics) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileReader
- loadClass(String) - Method in class org.apache.hadoop.hbase.util.CoprocessorClassLoader
- loadClass(String) - Method in class org.apache.hadoop.hbase.util.DynamicClassLoader
- loadClass(String, String[]) - Method in class org.apache.hadoop.hbase.util.CoprocessorClassLoader
- loadColumnFamiliesOnDemand - Variable in class org.apache.hadoop.hbase.client.Query
- loadConfiguration(Configuration) - Static method in class org.apache.hadoop.hbase.io.hfile.PrefetchExecutor
- loadDataBlockWithScanInfo(ExtendedCell, HFileBlock, boolean, boolean, boolean, DataBlockEncoding, HFile.CachingBlockReader) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileIndexBlockEncoder.EncodedSeeker
- loadDataBlockWithScanInfo(ExtendedCell, HFileBlock, boolean, boolean, boolean, DataBlockEncoding, HFile.CachingBlockReader) - Method in class org.apache.hadoop.hbase.io.hfile.NoOpIndexBlockEncoder.NoOpEncodedSeeker
- loadFileInfo() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileReader
- loadFiles(List<HStoreFile>) - Method in interface org.apache.hadoop.hbase.regionserver.StoreFileManager
-
Loads the initial store files into empty StoreFileManager.
- loadFiles(List<HStoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
- loadFromResource(Configuration, String, int) - Static method in class org.apache.hadoop.hbase.io.compress.DictionaryCache
- loadHdfsRegionDirs() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.Scan HDFS for all regions, recording their information into regionInfoMap
- loadHdfsRegioninfo(Configuration) - Method in class org.apache.hadoop.hbase.util.HbckRegionInfo
-
Read the .regioninfo file from the file system.
- loadLastFlushedSequenceIds() - Method in class org.apache.hadoop.hbase.master.ServerManager
-
Load last flushed sequence id of each region from HDFS, if persisted
- loadNumericRows(Table, byte[], int, int) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- loadRandomRows(Table, byte[], int, int) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- loadRegion(HRegion, byte[]) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- loadRegion(HRegion, byte[], boolean) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Load region with rows from 'aaa' to 'zzz'.
- loadRegion(Region, byte[]) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- loadRegionInfoFileContent(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
Create a
RegionInfo
from the serialized version on-disk. - loadResourceUsingParentFirst(String) - Method in class org.apache.hadoop.hbase.util.CoprocessorClassLoader
-
Determines whether we should attempt to load the given resource using the parent first before attempting to load the resource using this ClassLoader.
- loadSequence - Variable in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
- loadSystemCoprocessors(Configuration, String) - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
-
Load system coprocessors once only.
- loadTable() - Method in class org.apache.hadoop.hbase.util.LoadTestTool
- loadTable(Table, byte[]) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Load table with rows from 'aaa' to 'zzz'.
- loadTable(Table, byte[][]) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Load table of multiple column families with rows from 'aaa' to 'zzz'.
- loadTable(Table, byte[][], byte[]) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Load table of multiple column families with rows from 'aaa' to 'zzz'.
- loadTable(Table, byte[][], byte[], boolean) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Load table of multiple column families with rows from 'aaa' to 'zzz'.
- loadTable(Table, byte[], boolean) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Load table with rows from 'aaa' to 'zzz'.
- org.apache.hadoop.hbase.util.LoadTestDataGeneratorWithMOB - Class in org.apache.hadoop.hbase.util
-
A load test data generator for MOB
- LoadTestDataGeneratorWithMOB(byte[]...) - Constructor for class org.apache.hadoop.hbase.util.LoadTestDataGeneratorWithMOB
- LoadTestDataGeneratorWithMOB(int, int, int, int, byte[]...) - Constructor for class org.apache.hadoop.hbase.util.LoadTestDataGeneratorWithMOB
- org.apache.hadoop.hbase.util.LoadTestDataGeneratorWithTags - Class in org.apache.hadoop.hbase.util
- LoadTestDataGeneratorWithTags(int, int, int, int, byte[]...) - Constructor for class org.apache.hadoop.hbase.util.LoadTestDataGeneratorWithTags
- org.apache.hadoop.hbase.util.LoadTestKVGenerator - Class in org.apache.hadoop.hbase.util
-
A generator of random keys and values for load testing.
- LoadTestKVGenerator(int, int) - Constructor for class org.apache.hadoop.hbase.util.LoadTestKVGenerator
- org.apache.hadoop.hbase.util.LoadTestTool - Class in org.apache.hadoop.hbase.util
-
A command-line utility that reads, writes, and verifies data.
- LoadTestTool() - Constructor for class org.apache.hadoop.hbase.util.LoadTestTool
- org.apache.hadoop.hbase.util.LoadTestUtil - Class in org.apache.hadoop.hbase.util
-
This class was created by moving all load test related code from HFileTestUtil and HBaseTestingUtil as part of refactoring for hbase-diagnostics module creation in HBASE-28432
- LoadTestUtil() - Constructor for class org.apache.hadoop.hbase.util.LoadTestUtil
- loadTruststore(String, Optional<String>, Optional<String>) - Static method in class org.apache.hadoop.hbase.rest.client.Client
-
Loads a trustStore from the local fileSystem.
- loadValue(byte[], byte[], ByteBuffer) - Method in class org.apache.hadoop.hbase.client.Result
-
Loads the latest version of the specified column into the provided
ByteBuffer
. - loadValue(byte[], int, int, byte[], int, int, ByteBuffer) - Method in class org.apache.hadoop.hbase.client.Result
-
Loads the latest version of the specified column into the provided
ByteBuffer
. - LOCAL - Static variable in class org.apache.hadoop.hbase.LocalHBaseCluster
-
local mode
- LOCAL_BYTES_READ - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- LOCAL_BYTES_READ_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- LOCAL_COLON - Static variable in class org.apache.hadoop.hbase.LocalHBaseCluster
-
'local:'
- LOCAL_DIR_KEY - Static variable in class org.apache.hadoop.hbase.util.ClassLoaderBase
- localAddr - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
- org.apache.hadoop.hbase.LocalHBaseCluster - Class in org.apache.hadoop.hbase
-
This class creates a single process HBase cluster.
- LocalHBaseCluster(Configuration) - Constructor for class org.apache.hadoop.hbase.LocalHBaseCluster
-
Constructor.
- LocalHBaseCluster(Configuration, int) - Constructor for class org.apache.hadoop.hbase.LocalHBaseCluster
-
Constructor.
- LocalHBaseCluster(Configuration, int, int) - Constructor for class org.apache.hadoop.hbase.LocalHBaseCluster
-
Constructor.
- LocalHBaseCluster(Configuration, int, int, int, Class<? extends HMaster>, Class<? extends HRegionServer>) - Constructor for class org.apache.hadoop.hbase.LocalHBaseCluster
-
Constructor.
- LocalHBaseCluster(Configuration, int, int, Class<? extends HMaster>, Class<? extends HRegionServer>) - Constructor for class org.apache.hadoop.hbase.LocalHBaseCluster
- LocalHMaster(Configuration) - Constructor for class org.apache.hadoop.hbase.master.HMasterCommandLine.LocalHMaster
- LOCALHOST - Static variable in class org.apache.hadoop.hbase.HConstants
-
Host name of the local machine
- LOCALHOST_IP - Static variable in class org.apache.hadoop.hbase.HConstants
- LOCALITY - Enum constant in enum class org.apache.hadoop.hbase.hbtop.field.Field
- LOCALITY_SENSITIVE_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
-
Keep locality while generating HFiles for bulkload.
- LocalShell(String, String) - Constructor for class org.apache.hadoop.hbase.chaos.ChaosAgent.LocalShell
- org.apache.hadoop.hbase.util.LocatedBlockHelper - Class in org.apache.hadoop.hbase.util
-
hadoop 3.3.1 changed the return value of this method from
DatanodeInfo[]
toDatanodeInfoWithStorage[]
, which causes the JVM can not locate the method if we are compiled with hadoop 3.2 and then link with hadoop 3.3+, so here we need to use reflection to make it work for both hadoop versions, otherwise we need to publish more artifacts for different hadoop versions... - LOCATOR_META_REPLICAS_MODE - Static variable in interface org.apache.hadoop.hbase.client.RegionLocator
-
Configuration for Region Locator's mode when meta replica is configured.
- LOCATOR_META_REPLICAS_MODE_LOADBALANCE_SELECTOR - Static variable in interface org.apache.hadoop.hbase.client.RegionLocator
-
Configuration for meta replica selector when Region Locator's LoadBalance mode is configured.
- lockHeartbeat(RpcController, LockServiceProtos.LockHeartbeatRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- LockHeartbeatWorker(String) - Constructor for class org.apache.hadoop.hbase.client.locking.EntityLock.LockHeartbeatWorker
- org.apache.hadoop.hbase.client.locking.LockServiceClient - Class in org.apache.hadoop.hbase.client.locking
-
Helper class to create "master locks" for namespaces, tables and regions.
- LockServiceClient(Configuration, LockServiceProtos.LockService.BlockingInterface, NonceGenerator) - Constructor for class org.apache.hadoop.hbase.client.locking.LockServiceClient
- LOG - Static variable in class org.apache.hadoop.hbase.backup.HBackupFileSystem
- LOG - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
- LOG - Static variable in class org.apache.hadoop.hbase.codec.BaseDecoder
- LOG - Static variable in class org.apache.hadoop.hbase.HBaseCommonTestingUtility
-
Deprecated.
- LOG - Static variable in class org.apache.hadoop.hbase.io.hfile.ChecksumUtil
- LOG - Static variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
- LOG - Static variable in class org.apache.hadoop.hbase.ipc.NettyRpcServer
- LOG - Static variable in class org.apache.hadoop.hbase.ipc.RpcServer
- LOG - Static variable in class org.apache.hadoop.hbase.ipc.RpcServerFactory
- LOG - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv
- LOG - Static variable in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl
- LOG - Static variable in class org.apache.hadoop.hbase.master.CachedClusterId
- LOG - Static variable in class org.apache.hadoop.hbase.MockRegionServerServices
- LOG - Static variable in class org.apache.hadoop.hbase.regionserver.MemStoreCompactionStrategy
- LOG - Static variable in class org.apache.hadoop.hbase.zookeeper.ZKNodeTracker
- LOG_BAD_LINES_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv
- LOG_PER_ROW_COUNT - Static variable in class org.apache.hadoop.hbase.mapreduce.TableRecordReaderImpl
- LOG_SCANNER_ACTIVITY - Static variable in class org.apache.hadoop.hbase.client.ConnectionConfiguration
- LOG2_SQUARED - Static variable in class org.apache.hadoop.hbase.util.BloomFilterUtil
-
Used in computing the optimal Bloom filter size.
- org.apache.hadoop.hbase.logging.Log4jUtils - Class in org.apache.hadoop.hbase.logging
-
A bridge class for operating on log4j, such as changing log level, etc.
- logCloseRequested() - Method in interface org.apache.hadoop.hbase.regionserver.wal.WALActionsListener
-
The WAL is about to close.
- logDir - Variable in class org.apache.hadoop.hbase.http.HttpServer
- LogEntry - Class in org.apache.hadoop.hbase.client
-
Abstract response class representing online logs response from ring-buffer use-cases e.g slow/large RPC logs, balancer decision logs
- LogEntry() - Constructor for class org.apache.hadoop.hbase.client.LogEntry
- logFileSystemState(FileSystem, Path, Logger) - Static method in class org.apache.hadoop.hbase.util.CommonFSUtils
-
Log the current state of the filesystem from a certain root directory
- logFileSystemState(Logger) - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
- LOGGING_EXCEPTION_HANDLER - Static variable in class org.apache.hadoop.hbase.util.Threads
- org.apache.hadoop.hbase.namequeues.LogHandlerUtils - Class in org.apache.hadoop.hbase.namequeues
-
Event Handler utility class
- LogHandlerUtils() - Constructor for class org.apache.hadoop.hbase.namequeues.LogHandlerUtils
- login(String, String) - Static method in class org.apache.hadoop.hbase.security.User
-
Login with the given keytab and principal.
- login(String, String) - Static method in class org.apache.hadoop.hbase.security.User.SecureHadoopUser
-
Login through configured keytab and pricipal.
- login(String, String) - Method in class org.apache.hadoop.hbase.security.UserProvider
-
Login with given keytab and principal.
- login(String, String, String) - Method in class org.apache.hadoop.hbase.security.UserProvider
-
Log in the current process using the given configuration keys for the credential file and login principal.
- login(Configuration, String, String, String) - Static method in class org.apache.hadoop.hbase.security.User
-
Log in the current process using the given configuration keys for the credential file and login principal.
- login(Configuration, String, String, String) - Static method in class org.apache.hadoop.hbase.security.User.SecureHadoopUser
-
Obtain credentials for the current process using the configured Kerberos keytab file and principal.
- login(UserProvider, String) - Method in class org.apache.hadoop.hbase.HBaseServerBase
- login(UserProvider, String) - Method in class org.apache.hadoop.hbase.master.HMaster
-
For compatibility, if failed with regionserver credentials, try the master one
- login(UserProvider, String) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
- loginAndReturnUGI(Configuration, String) - Static method in class org.apache.hadoop.hbase.util.KerberosUtils
-
Logs in a user using Kerberos keytab and returns the UserGroupInformation (UGI) instance.
- loginClient(Configuration) - Static method in class org.apache.hadoop.hbase.AuthUtil
-
Deprecated.For kerberized cluster, return login user (from kinit or from keytab if specified).
- loginClient(Configuration, String, String, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAuthentication
-
Log in the current zookeeper client using the given configuration keys for the credential file and login principal.
- loginServer(Configuration, String, String, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAuthentication
-
Log in the current zookeeper server process using the given configuration keys for the credential file and login principal.
- logJVMInfo() - Static method in class org.apache.hadoop.hbase.util.ServerCommandLine
-
Log information about the currently running JVM.
- org.apache.hadoop.hbase.http.log.LogLevel - Class in org.apache.hadoop.hbase.http.log
-
Change log level in runtime.
- org.apache.hadoop.hbase.http.log.LogLevel.Servlet - Class in org.apache.hadoop.hbase.http.log
-
A servlet implementation
- org.apache.hadoop.hbase.util.LogMonitoring - Class in org.apache.hadoop.hbase.util
-
Utility functions for reading the log4j logs that are being written by HBase.
- LogMonitoring() - Constructor for class org.apache.hadoop.hbase.util.LogMonitoring
- logPrefix - Variable in class org.apache.hadoop.hbase.wal.AbstractWALProvider
- logProcessInfo(Configuration) - Static method in class org.apache.hadoop.hbase.util.ServerCommandLine
-
Logs information about the currently running JVM process including the environment variables.
- LogQueryFilter - Class in org.apache.hadoop.hbase.client
-
Deprecated.as of 2.4.0. Will be removed in 4.0.0.
- LogQueryFilter() - Constructor for class org.apache.hadoop.hbase.client.LogQueryFilter
-
Deprecated.
- org.apache.hadoop.hbase.client.LogQueryFilter.FilterByOperator - Enum Class in org.apache.hadoop.hbase.client
-
Deprecated.
- org.apache.hadoop.hbase.client.LogQueryFilter.Type - Enum Class in org.apache.hadoop.hbase.client
-
Deprecated.
- logRollAndSetupWalProps(Path, Path, long) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
- org.apache.hadoop.hbase.regionserver.LogRoller - Class in org.apache.hadoop.hbase.regionserver
-
Runs periodically to determine if the WAL should be rolled.
- LogRoller(RegionServerServices) - Constructor for class org.apache.hadoop.hbase.regionserver.LogRoller
- logRollRequested(WALActionsListener.RollRequestReason) - Method in class org.apache.hadoop.hbase.regionserver.wal.MetricsWAL
- logRollRequested(WALActionsListener.RollRequestReason) - Method in interface org.apache.hadoop.hbase.regionserver.wal.WALActionsListener
-
A request was made that the WAL be rolled.
- logrollsize - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
- logStats() - Method in class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache
- logStats() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
- logStats() - Method in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
- logThreadInfo(Logger, String, long) - Static method in class org.apache.hadoop.hbase.util.ReflectionUtils
-
Log the current thread stacks at INFO level.
- logVersion() - Static method in class org.apache.hadoop.hbase.util.VersionInfo
- logZKTree(ZKWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Recursively print the current state of ZK (non-transactional)
- LONG - Enum constant in enum class org.apache.hadoop.hbase.hbtop.field.FieldValueType
- LONG - Enum constant in enum class org.apache.hadoop.hbase.util.PrettyPrinter.Unit
- LONG_HELP_OPTION - Static variable in class org.apache.hadoop.hbase.util.AbstractHBaseTool
- LONG_REGION_SERVER - Enum constant in enum class org.apache.hadoop.hbase.hbtop.field.Field
- org.apache.hadoop.hbase.filter.LongComparator - Class in org.apache.hadoop.hbase.filter
-
A long comparator which numerical compares against the specified byte array
- LongComparator(long) - Constructor for class org.apache.hadoop.hbase.filter.LongComparator
- longFitsIn(long) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Check how many bytes are required to store value.
- LOOPBACK_HOST - Static variable in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
- org.apache.hadoop.hbase.util.LossyCounting<T> - Class in org.apache.hadoop.hbase.util
-
LossyCounting utility, bounded data structure that maintains approximate high frequency elements in data stream.
- LossyCounting(String, double, LossyCounting.LossyCountingListener<T>) - Constructor for class org.apache.hadoop.hbase.util.LossyCounting
- LossyCounting(String, Configuration, LossyCounting.LossyCountingListener<T>) - Constructor for class org.apache.hadoop.hbase.util.LossyCounting
- org.apache.hadoop.hbase.util.LossyCounting.LossyCountingListener<T> - Interface in org.apache.hadoop.hbase.util
- LOW_REPLICA_ROLL_REQUESTED - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
- LOW_REPLICA_ROLL_REQUESTED_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
- LOW_REPLICATION - Enum constant in enum class org.apache.hadoop.hbase.regionserver.wal.WALActionsListener.RollRequestReason
-
Too few replicas in the writer pipeline.
- lower(T) - Method in class org.apache.hadoop.hbase.regionserver.CellSet
- lowerEntry(K) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
- lowerEntry(T) - Method in class org.apache.hadoop.hbase.regionserver.CellFlatMap
- lowerKey(K) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
- lowerKey(T) - Method in class org.apache.hadoop.hbase.regionserver.CellFlatMap
- LOWESTKEY - Static variable in class org.apache.hadoop.hbase.KeyValue
-
Lowest possible key.
- LPAREN - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
ASCII code for LPAREN
- LPAREN_ARRAY - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
LPAREN Array
- LPAREN_BUFFER - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
- org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache - Class in org.apache.hadoop.hbase.io.hfile
-
This realisation improve performance of classical LRU cache up to 3 times via reduce GC job.
- LruAdaptiveBlockCache(long, long) - Constructor for class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache
-
Default constructor.
- LruAdaptiveBlockCache(long, long, boolean) - Constructor for class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache
-
Constructor used for testing.
- LruAdaptiveBlockCache(long, long, boolean, int, float, int, float, float, float, float, float, float, boolean, long, int, long, float) - Constructor for class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache
-
Configurable constructor.
- LruAdaptiveBlockCache(long, long, boolean, Configuration) - Constructor for class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache
- LruAdaptiveBlockCache(long, long, Configuration) - Constructor for class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache
- org.apache.hadoop.hbase.io.hfile.LruBlockCache - Class in org.apache.hadoop.hbase.io.hfile
-
A block cache implementation that is memory-aware using
HeapSize
, memory-bound using an LRU eviction algorithm, and concurrent: backed by aConcurrentHashMap
and with a non-blocking eviction thread giving constant-timeLruBlockCache.cacheBlock(org.apache.hadoop.hbase.io.hfile.BlockCacheKey, org.apache.hadoop.hbase.io.hfile.Cacheable, boolean)
andLruBlockCache.getBlock(org.apache.hadoop.hbase.io.hfile.BlockCacheKey, boolean, boolean, boolean)
operations. - LruBlockCache(long, long) - Constructor for class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
Default constructor.
- LruBlockCache(long, long, boolean) - Constructor for class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
Constructor used for testing.
- LruBlockCache(long, long, boolean, int, float, int, float, float, float, float, float, float, boolean, long) - Constructor for class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
Configurable constructor.
- LruBlockCache(long, long, boolean, Configuration) - Constructor for class org.apache.hadoop.hbase.io.hfile.LruBlockCache
- LruBlockCache(long, long, Configuration) - Constructor for class org.apache.hadoop.hbase.io.hfile.LruBlockCache
- org.apache.hadoop.hbase.io.hfile.LruCachedBlock - Class in org.apache.hadoop.hbase.io.hfile
-
Represents an entry in the
LruBlockCache
. - LruCachedBlock(BlockCacheKey, Cacheable, long) - Constructor for class org.apache.hadoop.hbase.io.hfile.LruCachedBlock
- LruCachedBlock(BlockCacheKey, Cacheable, long, boolean) - Constructor for class org.apache.hadoop.hbase.io.hfile.LruCachedBlock
- org.apache.hadoop.hbase.io.hfile.LruCachedBlockQueue - Class in org.apache.hadoop.hbase.io.hfile
-
A memory-bound queue that will grow until an element brings total size >= maxSize.
- LruCachedBlockQueue(long, long) - Constructor for class org.apache.hadoop.hbase.io.hfile.LruCachedBlockQueue
- org.apache.hadoop.hbase.io.util.LRUDictionary - Class in org.apache.hadoop.hbase.io.util
-
WALDictionary using an LRU eviction algorithm.
- LRUDictionary() - Constructor for class org.apache.hadoop.hbase.io.util.LRUDictionary
- LZ4 - Enum constant in enum class org.apache.hadoop.hbase.io.compress.Compression.Algorithm
- LZ4_CODEC_CLASS_DEFAULT - Static variable in class org.apache.hadoop.hbase.io.compress.Compression
- LZ4_CODEC_CLASS_KEY - Static variable in class org.apache.hadoop.hbase.io.compress.Compression
- LZMA - Enum constant in enum class org.apache.hadoop.hbase.io.compress.Compression.Algorithm
- LZMA_CODEC_CLASS_DEFAULT - Static variable in class org.apache.hadoop.hbase.io.compress.Compression
- LZMA_CODEC_CLASS_KEY - Static variable in class org.apache.hadoop.hbase.io.compress.Compression
- LZO - Enum constant in enum class org.apache.hadoop.hbase.io.compress.Compression.Algorithm
- LZO_CODEC_CLASS_DEFAULT - Static variable in class org.apache.hadoop.hbase.io.compress.Compression
- LZO_CODEC_CLASS_KEY - Static variable in class org.apache.hadoop.hbase.io.compress.Compression
M
- MACHINE - Enum constant in enum class org.apache.hadoop.hbase.quotas.QuotaScope
-
The specified throttling rules will be applied on the machine level.
- MAGENTA - Enum constant in enum class org.apache.hadoop.hbase.hbtop.terminal.Color
- MAGIC_LENGTH - Static variable in enum class org.apache.hadoop.hbase.io.hfile.BlockType
- main(String[]) - Static method in class org.apache.hadoop.hbase.backup.BackupDriver
- main(String[]) - Static method in class org.apache.hadoop.hbase.backup.RestoreDriver
- main(String[]) - Static method in class org.apache.hadoop.hbase.chaos.ChaosService
- main(String[]) - Static method in class org.apache.hadoop.hbase.client.example.AsyncClientExample
- main(String[]) - Static method in class org.apache.hadoop.hbase.client.example.BufferedMutatorExample
- main(String[]) - Static method in class org.apache.hadoop.hbase.client.example.ExportEndpointExample
- main(String[]) - Static method in class org.apache.hadoop.hbase.client.example.HttpProxyExample
- main(String[]) - Static method in class org.apache.hadoop.hbase.client.example.MultiThreadedClientExample
- main(String[]) - Static method in class org.apache.hadoop.hbase.client.example.RefreshHFilesClient
- main(String[]) - Static method in class org.apache.hadoop.hbase.HBaseConfiguration
-
For debugging.
- main(String[]) - Static method in class org.apache.hadoop.hbase.hbtop.HBTop
- main(String[]) - Static method in class org.apache.hadoop.hbase.HFilePerformanceEvaluation
- main(String[]) - Static method in class org.apache.hadoop.hbase.http.HtmlQuoting
- main(String[]) - Static method in class org.apache.hadoop.hbase.http.log.LogLevel
-
A command line implementation
- main(String[]) - Static method in class org.apache.hadoop.hbase.io.compress.Compression
- main(String[]) - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
- main(String[]) - Static method in class org.apache.hadoop.hbase.io.hfile.HFilePrettyPrinter
- main(String[]) - Static method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
Test things basically work.
- main(String[]) - Static method in class org.apache.hadoop.hbase.mapred.Driver
- main(String[]) - Static method in class org.apache.hadoop.hbase.mapred.RowCounter
- main(String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.CellCounter
-
Main entry point.
- main(String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.CopyTable
-
Main entry point.
- main(String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.Driver
- main(String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.Export
-
Main entry point.
- main(String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.HashTable
-
Main entry point.
- main(String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.Import
-
Main entry point.
- main(String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.ImportTsv
- main(String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.IndexBuilder
- main(String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.RoundRobinTableInputFormat
-
Pass table name as argument.
- main(String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.RowCounter
-
Main entry point.
- main(String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.SampleUploader
- main(String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.SyncTable
-
Main entry point.
- main(String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.WALPlayer
-
Main entry point.
- main(String[]) - Static method in class org.apache.hadoop.hbase.master.HMaster
- main(String[]) - Static method in class org.apache.hadoop.hbase.master.RegionPlacementMaintainer
- main(String[]) - Static method in class org.apache.hadoop.hbase.mob.ExpiredMobFileCleaner
- main(String[]) - Static method in class org.apache.hadoop.hbase.mob.mapreduce.MobRefReporter
- main(String[]) - Static method in class org.apache.hadoop.hbase.PerformanceEvaluation
- main(String[]) - Static method in class org.apache.hadoop.hbase.regionserver.CompactionTool
- main(String[]) - Static method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore
-
Code to help figure if our approximation of object heap sizes is close enough.
- main(String[]) - Static method in class org.apache.hadoop.hbase.regionserver.DumpRegionServerMetrics
- main(String[]) - Static method in class org.apache.hadoop.hbase.regionserver.HRegionServer
- main(String[]) - Static method in class org.apache.hadoop.hbase.regionserver.ScannerIdGenerator
- main(String[]) - Static method in class org.apache.hadoop.hbase.regionserver.ShutdownHook
-
Main to test basic functionality.
- main(String[]) - Static method in class org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileListFilePrettyPrinter
- main(String[]) - Static method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
Pass one or more log file names, and it will either dump out a text version on
stdout
or split the specified log files. - main(String[]) - Static method in class org.apache.hadoop.hbase.regionserver.wal.Compressor
-
Command line tool to compress and uncompress WALs.
- main(String[]) - Static method in class org.apache.hadoop.hbase.replication.CopyReplicationPeers
- main(String[]) - Static method in class org.apache.hadoop.hbase.rest.RESTServer
-
The main method for the HBase rest server.
- main(String[]) - Static method in class org.apache.hadoop.hbase.rsgroup.RSGroupMajorCompactionTTL
- main(String[]) - Static method in class org.apache.hadoop.hbase.ScanPerformanceEvaluation
- main(String[]) - Static method in class org.apache.hadoop.hbase.snapshot.CreateSnapshot
- main(String[]) - Static method in class org.apache.hadoop.hbase.snapshot.ExportSnapshot
- main(String[]) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo
- main(String[]) - Static method in class org.apache.hadoop.hbase.thrift.DemoClient
- main(String[]) - Static method in class org.apache.hadoop.hbase.thrift.HttpDoAsClient
- main(String[]) - Static method in class org.apache.hadoop.hbase.thrift.ThriftServer
- main(String[]) - Static method in class org.apache.hadoop.hbase.util.compaction.MajorCompactor
- main(String[]) - Static method in class org.apache.hadoop.hbase.util.compaction.MajorCompactorTTL
- main(String[]) - Static method in class org.apache.hadoop.hbase.util.CompressionTest
- main(String[]) - Static method in class org.apache.hadoop.hbase.util.GetJavaProperty
- main(String[]) - Static method in class org.apache.hadoop.hbase.util.HBaseConfTool
- main(String[]) - Static method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.Main program
- main(String[]) - Static method in class org.apache.hadoop.hbase.util.JenkinsHash
-
Compute the hash of the specified file
- main(String[]) - Static method in class org.apache.hadoop.hbase.util.JvmPauseMonitor
-
Simple 'main' to facilitate manual testing of the pause monitor.
- main(String[]) - Static method in class org.apache.hadoop.hbase.util.LoadTestTool
- main(String[]) - Static method in class org.apache.hadoop.hbase.util.MapreduceDependencyClasspathTool
- main(String[]) - Static method in class org.apache.hadoop.hbase.util.Random64
-
Random64 is a pseudorandom algorithm(LCG).
- main(String[]) - Static method in class org.apache.hadoop.hbase.util.RegionMover
- main(String[]) - Static method in class org.apache.hadoop.hbase.util.RegionSplitter
-
The main function for the RegionSplitter application.
- main(String[]) - Static method in class org.apache.hadoop.hbase.util.VersionInfo
- main(String[]) - Static method in class org.apache.hadoop.hbase.wal.WALPerformanceEvaluation
- main(String[]) - Static method in class org.apache.hadoop.hbase.wal.WALPrettyPrinter
- main(String[]) - Static method in class org.apache.hadoop.hbase.zookeeper.HQuorumPeer
-
Parse ZooKeeper configuration from HBase XML config and run a QuorumPeer.
- main(String[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAclReset
- main(String[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKMainServer
-
Run the tool.
- main(String[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKServerTool
-
Run the tool.
- main(String[]) - Static method in class org.apache.hbase.archetypes.exemplars.client.HelloHBase
- main(String[]) - Static method in class org.apache.hbase.archetypes.exemplars.shaded_client.HelloHBase
- MAJOR - Enum constant in enum class org.apache.hadoop.hbase.client.CompactionState
- MAJOR_AND_MINOR - Enum constant in enum class org.apache.hadoop.hbase.client.CompactionState
- MAJOR_COMPACTED_CELLS - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- MAJOR_COMPACTED_CELLS_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- MAJOR_COMPACTED_CELLS_SIZE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- MAJOR_COMPACTED_CELLS_SIZE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- MAJOR_COMPACTED_INPUT_BYTES - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- MAJOR_COMPACTED_INPUT_BYTES_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- MAJOR_COMPACTED_OUTPUT_BYTES - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- MAJOR_COMPACTED_OUTPUT_BYTES_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- MAJOR_COMPACTION_INPUT_FILE_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- MAJOR_COMPACTION_INPUT_FILE_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- MAJOR_COMPACTION_INPUT_SIZE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- MAJOR_COMPACTION_INPUT_SIZE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- MAJOR_COMPACTION_JITTER - Static variable in class org.apache.hadoop.hbase.HConstants
-
Parameter name and default value for major compaction jitter.
- MAJOR_COMPACTION_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.HStoreFile
-
Major compaction flag in FileInfo
- MAJOR_COMPACTION_OUTPUT_FILE_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- MAJOR_COMPACTION_OUTPUT_FILE_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- MAJOR_COMPACTION_OUTPUT_SIZE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- MAJOR_COMPACTION_OUTPUT_SIZE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- MAJOR_COMPACTION_PERIOD - Static variable in class org.apache.hadoop.hbase.HConstants
-
Parameter name and default value for how often a region should perform a major compaction
- MAJOR_COMPACTION_TIME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- MAJOR_COMPACTION_TIME_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- MAJOR_VERSION - Static variable in exception org.apache.hadoop.hbase.exceptions.RequestTooBigException
- majorCompact(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
- majorCompact(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Major compact a table.
- majorCompact(TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Major compact a table.
- majorCompact(TableName, byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Major compact a column family within a table.
- majorCompact(TableName, byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Major compact a column family within a table.
- majorCompact(TableName, byte[], CompactType) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Major compact a column family within a table.
- majorCompact(TableName, byte[], CompactType) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Major compact a column family within a table.
- majorCompact(TableName, CompactType) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Major compact a table.
- majorCompact(TableName, CompactType) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Major compact a table.
- org.apache.hadoop.hbase.regionserver.querymatcher.MajorCompactionScanQueryMatcher - Class in org.apache.hadoop.hbase.regionserver.querymatcher
-
Query matcher for major compaction.
- MajorCompactionScanQueryMatcher(ScanInfo, DeleteTracker, ColumnTracker, long, long, long, long) - Constructor for class org.apache.hadoop.hbase.regionserver.querymatcher.MajorCompactionScanQueryMatcher
- org.apache.hadoop.hbase.util.compaction.MajorCompactionTTLRequest - Class in org.apache.hadoop.hbase.util.compaction
-
This request helps determine if a region has to be compacted based on table's TTL.
- org.apache.hadoop.hbase.util.compaction.MajorCompactor - Class in org.apache.hadoop.hbase.util.compaction
- MajorCompactor(Configuration, TableName, Set<String>, int, long, long) - Constructor for class org.apache.hadoop.hbase.util.compaction.MajorCompactor
- org.apache.hadoop.hbase.util.compaction.MajorCompactorTTL - Class in org.apache.hadoop.hbase.util.compaction
-
This tool compacts a table's regions that are beyond it's TTL.
- MajorCompactorTTL() - Constructor for class org.apache.hadoop.hbase.util.compaction.MajorCompactorTTL
- MajorCompactorTTL(Configuration, TableDescriptor, int, long) - Constructor for class org.apache.hadoop.hbase.util.compaction.MajorCompactorTTL
- majorCompactRegion(byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Major compact a table or an individual region.
- majorCompactRegion(byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Major compact a region.
- majorCompactRegion(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Major compact a column family within region.
- majorCompactRegion(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Major compact a column family within region.
- majorCompactRegionServer(ServerName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Major compact all regions on the region server.
- majorCompactRegionServer(ServerName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Compact all regions on the region server.
- makeColumn(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Makes a column in family:qualifier form from separate byte arrays.
- makeDeleteFromRegionInfo(RegionInfo, long) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Generates and returns a Delete containing the region info for the catalog table
- makeFilter(QuotaFilter) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
converts quotafilter to serializeable filterlists.
- makeGetForNamespaceQuotas(String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
- makeGetForRegionServerQuotas(String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
- makeGetForTableQuotas(TableName) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
- makeGetForUserQuotas(String, Iterable<TableName>, Iterable<String>) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
- makePutForReplicationBarrier(RegionInfo, long, long) - Static method in class org.apache.hadoop.hbase.replication.ReplicationBarrierFamilyFormat
- makePutFromRegionInfo(RegionInfo) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Generates and returns a
Put
containing theRegionInfo
for the catalog table. - makePutFromRegionInfo(RegionInfo, long) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Generates and returns a
Put
containing theRegionInfo
for the catalog table. - makePutFromTableState(TableState, long) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Construct PUT for given state
- makeQuotaSnapshotGetForTable(TableName) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
Creates a
Get
which returns onlySpaceQuotaSnapshot
from the quota table for a specific table. - makeQuotaSnapshotScan() - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
Creates a
Scan
which returns only quota snapshots from the quota table. - makeQuotaSnapshotScanForTable(TableName) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
Creates a
Scan
which returns onlySpaceQuotaSnapshot
from the quota table for a specific table. - makeScan(QuotaFilter) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
- makeZKProps(Configuration) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKConfig
-
Make a Properties object holding ZooKeeper config.
- org.apache.hadoop.hbase.util.ManualEnvironmentEdge - Class in org.apache.hadoop.hbase.util
-
An environment edge that uses a manually set value.
- ManualEnvironmentEdge() - Constructor for class org.apache.hadoop.hbase.util.ManualEnvironmentEdge
- org.apache.hadoop.hbase.mob.ManualMobMaintHFileCleaner - Class in org.apache.hadoop.hbase.mob
-
BaseHFileCleanerDelegate
that prevents cleaning HFiles from a mob region keeps a map of table name strings to mob region name strings over the life of a JVM instance. - ManualMobMaintHFileCleaner() - Constructor for class org.apache.hadoop.hbase.mob.ManualMobMaintHFileCleaner
- map(ImmutableBytesWritable, Result, OutputCollector<ImmutableBytesWritable, Result>, Reporter) - Method in class org.apache.hadoop.hbase.mapred.GroupingTableMap
-
Extract the grouping columns from value to construct a new key.
- map(ImmutableBytesWritable, Result, OutputCollector<ImmutableBytesWritable, Result>, Reporter) - Method in class org.apache.hadoop.hbase.mapred.IdentityTableMap
-
Pass the key, value to reduce
- map(ImmutableBytesWritable, Result, Mapper.Context) - Method in class org.apache.hadoop.hbase.ScanPerformanceEvaluation.MyMapper
- map(ImmutableBytesWritable, Result, Mapper.Context) - Method in class org.apache.hadoop.hbase.mapreduce.Import.CellImporter
- map(ImmutableBytesWritable, Result, Mapper.Context) - Method in class org.apache.hadoop.hbase.mapreduce.Import.Importer
- map(ImmutableBytesWritable, Result, Mapper.Context) - Method in class org.apache.hadoop.hbase.mapreduce.SyncTable.SyncMapper
- map(ImmutableBytesWritable, Result, Mapper.Context) - Method in class org.apache.hadoop.hbase.mapreduce.IndexBuilder.Map
- map(ImmutableBytesWritable, Result, Mapper.Context) - Method in class org.apache.hadoop.hbase.mapreduce.GroupingTableMapper
-
Extract the grouping columns from value to construct a new key.
- map(ImmutableBytesWritable, Result, Mapper.Context) - Method in class org.apache.hadoop.hbase.mapreduce.IdentityTableMapper
-
Pass the key, value to reduce.
- map(ImmutableBytesWritable, Result, Mapper.Context) - Method in class org.apache.hadoop.hbase.mapreduce.HashTable.HashMapper
- map(ImmutableBytesWritable, Result, Mapper.Context) - Method in class org.apache.hadoop.hbase.mapreduce.Import.CellSortImporter
- map(ImmutableBytesWritable, Result, Mapper.Context) - Method in class org.apache.hadoop.hbase.mob.mapreduce.MobRefReporter.MobRefMapper
- map(WALKey, WALEdit, Mapper.Context) - Method in class org.apache.hadoop.hbase.mapreduce.WALPlayer.WALMapper
- map(LongWritable, Text, Mapper.Context) - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
-
Convert a line of TSV text into an HBase table row.
- map(LongWritable, Text, Mapper.Context) - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterTextMapper
-
Convert a line of TSV text into an HBase table row.
- map(LongWritable, Text, Mapper.Context) - Method in class org.apache.hadoop.hbase.PerformanceEvaluation.EvaluationMapTask
- Map() - Constructor for class org.apache.hadoop.hbase.mapreduce.IndexBuilder.Map
- MAP_ENTRY - Static variable in class org.apache.hadoop.hbase.util.ClassSize
-
Overhead for entry in map
- mapKey(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Calculate a hash code from a given byte array suitable for use as a key in maps.
- mapKey(byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Calculate a hash code from a given byte array suitable for use as a key in maps.
- MAPPER_CLASS - Static variable in class org.apache.hadoop.hbase.mapreduce.MultithreadedTableMapper
- MAPPER_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv
- MAPREDUCE_INPUT_AUTOBALANCE - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
Specify if we enable auto-balance to set number of mappers in M/R jobs.
- org.apache.hadoop.hbase.util.MapreduceDependencyClasspathTool - Class in org.apache.hadoop.hbase.util
-
Generate a classpath string containing any jars required by mapreduce jobs.
- MapreduceDependencyClasspathTool() - Constructor for class org.apache.hadoop.hbase.util.MapreduceDependencyClasspathTool
- org.apache.hadoop.hbase.util.MapReduceExtendedCell - Class in org.apache.hadoop.hbase.util
-
A wrapper for a cell to be used with mapreduce, as the output value class for mappers/reducers.
- MapReduceExtendedCell(ExtendedCell) - Constructor for class org.apache.hadoop.hbase.util.MapReduceExtendedCell
- mark() - Method in interface org.apache.hadoop.hbase.metrics.Meter
-
Records one occurrence.
- mark() - Method in class org.apache.hadoop.hbase.nio.ByteBuff
-
Marks the current position of the ByteBuff
- mark() - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
Marks the current position of the MBB
- mark() - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
- mark(int) - Method in class org.apache.hadoop.hbase.io.FileLink.FileLinkInputStream
- mark(long) - Method in interface org.apache.hadoop.hbase.metrics.Meter
-
Records
events
occurrences. - markCompactedAway() - Method in class org.apache.hadoop.hbase.regionserver.HStoreFile
- markCorrupted(Path, String, FileSystem) - Method in interface org.apache.hadoop.hbase.coordination.SplitLogWorkerCoordination
-
Deprecated.marks log file as corrupted
- markCorrupted(Path, String, FileSystem) - Method in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination
- markCorrupted(Path, String, FileSystem) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog
-
Deprecated.
- markFutureDoneAndOffer(SyncFuture, long, Throwable) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
Helper that marks the future as DONE and offers it back to the cache.
- markSupported() - Method in class org.apache.hadoop.hbase.io.FileLink.FileLinkInputStream
- MASK_FOR_LOWER_INT_IN_LONG - Static variable in class org.apache.hadoop.hbase.util.Bytes
-
Mask to apply to a long to reveal the lower int only.
- MASTER - Enum constant in enum class org.apache.hadoop.hbase.client.ServerType
- MASTER - Enum constant in enum class org.apache.hadoop.hbase.ClusterMetrics.Option
-
metrics about master name
- MASTER - Enum constant in enum class org.apache.hadoop.hbase.util.DNS.ServerType
- MASTER - Static variable in class org.apache.hadoop.hbase.master.HMaster
- MASTER__META_TRANSITION_HANDLER_COUNT_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
- MASTER_ACTIVE_TIME_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
- MASTER_ACTIVE_TIME_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
- MASTER_ADDRS_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
Configuration key for the list of master host:ports
- MASTER_CHECK_COMPRESSION - Static variable in class org.apache.hadoop.hbase.util.TableDescriptorChecker
- MASTER_CHECK_ENCRYPTION - Static variable in class org.apache.hadoop.hbase.util.TableDescriptorChecker
- MASTER_CLOSE_REGION_THREADS - Static variable in class org.apache.hadoop.hbase.HConstants
- MASTER_CLOSE_REGION_THREADS_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
- MASTER_COPROCESSOR_CONF_KEY - Static variable in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
- MASTER_COPROCESSORS - Enum constant in enum class org.apache.hadoop.hbase.ClusterMetrics.Option
-
metrics about master coprocessors
- MASTER_FINISHED_INITIALIZATION_TIME_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
- MASTER_FINISHED_INITIALIZATION_TIME_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
- MASTER_HOSTNAME_KEY - Static variable in class org.apache.hadoop.hbase.util.DNS
- MASTER_IMPL - Static variable in class org.apache.hadoop.hbase.HConstants
-
Parameter name for what master implementation to use.
- MASTER_INFO_PORT - Enum constant in enum class org.apache.hadoop.hbase.ClusterMetrics.Option
-
metrics info port
- MASTER_INFO_PORT - Static variable in class org.apache.hadoop.hbase.HConstants
-
Configuration key for master web API port
- MASTER_KRB_KEYTAB_FILE - Static variable in class org.apache.hadoop.hbase.security.SecurityConstants
- MASTER_KRB_PRINCIPAL - Static variable in class org.apache.hadoop.hbase.security.SecurityConstants
-
Configuration keys for programmatic JAAS configuration for secured master and regionserver interaction
- MASTER_LOG_REPLAY_OPS_THREADS - Static variable in class org.apache.hadoop.hbase.HConstants
- MASTER_LOG_REPLAY_OPS_THREADS_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
- MASTER_MERGE_DISPATCH_THREADS - Static variable in class org.apache.hadoop.hbase.HConstants
-
Number of threads used to dispatch merge operations to the regionservers.
- MASTER_MERGE_DISPATCH_THREADS_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
- MASTER_META_SERVER_OPERATIONS_THREADS - Static variable in class org.apache.hadoop.hbase.HConstants
- MASTER_META_SERVER_OPERATIONS_THREADS_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
- MASTER_META_TRANSITION_HANDLER_COUNT - Static variable in class org.apache.hadoop.hbase.HConstants
- MASTER_OPEN_REGION_THREADS - Static variable in class org.apache.hadoop.hbase.HConstants
-
Configurations for master executor services.
- MASTER_OPEN_REGION_THREADS_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
- MASTER_PORT - Static variable in class org.apache.hadoop.hbase.HConstants
-
Parameter name for port master listens on.
- MASTER_REGISTRY_HEDGED_REQS_FANOUT_KEY - Static variable in class org.apache.hadoop.hbase.client.MasterRegistry
-
Deprecated.Configuration key that controls the fan out of requests
- MASTER_REGISTRY_INITIAL_REFRESH_DELAY_SECS - Static variable in class org.apache.hadoop.hbase.client.MasterRegistry
-
Deprecated.
- MASTER_REGISTRY_MIN_SECS_BETWEEN_REFRESHES - Static variable in class org.apache.hadoop.hbase.client.MasterRegistry
-
Deprecated.
- MASTER_REGISTRY_PERIODIC_REFRESH_INTERVAL_SECS - Static variable in class org.apache.hadoop.hbase.client.MasterRegistry
-
Deprecated.
- MASTER_RPC_SCHEDULER_FACTORY_CLASS - Static variable in class org.apache.hadoop.hbase.master.MasterRpcServices
-
RPC scheduler to use for the master.
- MASTER_SERVER_OPERATIONS_THREADS - Static variable in class org.apache.hadoop.hbase.HConstants
- MASTER_SERVER_OPERATIONS_THREADS_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
- MASTER_SERVER_REPORT_HANDLER_COUNT - Static variable in class org.apache.hadoop.hbase.ipc.MasterFifoRpcScheduler
-
Set RSReport requests handlers count when masters use MasterFifoRpcScheduler.
- MASTER_SNAPSHOT_TIMEOUT_MILLIS - Static variable in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
- MASTER_START_TIME_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
- MASTER_START_TIME_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
- MASTER_TYPE_BACKUP - Static variable in class org.apache.hadoop.hbase.HConstants
-
Parameter name for the master type being backup (waits for primary to go inactive).
- org.apache.hadoop.hbase.zookeeper.MasterAddressTracker - Class in org.apache.hadoop.hbase.zookeeper
-
Manages the location of the current active Master for the RegionServer.
- MasterAddressTracker(ZKWatcher, Abortable) - Constructor for class org.apache.hadoop.hbase.zookeeper.MasterAddressTracker
-
Construct a master address listener with the specified
zookeeper
reference. - masterAddressZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZNodePaths
- org.apache.hadoop.hbase.master.MasterAnnotationReadingPriorityFunction - Class in org.apache.hadoop.hbase.master
-
Priority function specifically for the master.
- masterClass(Class<? extends HMaster>) - Method in class org.apache.hadoop.hbase.StartMiniClusterOption.Builder
-
Deprecated.
- org.apache.hadoop.hbase.coprocessor.MasterCoprocessor - Interface in org.apache.hadoop.hbase.coprocessor
- org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment - Interface in org.apache.hadoop.hbase.coprocessor
- org.apache.hadoop.hbase.master.MasterCoprocessorHost - Class in org.apache.hadoop.hbase.master
-
Provides the coprocessor framework and environment for master oriented operations.
- MasterCoprocessorHost(MasterServices, Configuration) - Constructor for class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- org.apache.hadoop.hbase.ipc.MasterFifoRpcScheduler - Class in org.apache.hadoop.hbase.ipc
-
A special RpcScheduler} only used for master.
- MasterFifoRpcScheduler(Configuration, int, int) - Constructor for class org.apache.hadoop.hbase.ipc.MasterFifoRpcScheduler
- org.apache.hadoop.hbase.regionserver.MasterFifoRpcSchedulerFactory - Class in org.apache.hadoop.hbase.regionserver
-
Factory to use when you want to use the
MasterFifoRpcScheduler
- MasterFifoRpcSchedulerFactory() - Constructor for class org.apache.hadoop.hbase.regionserver.MasterFifoRpcSchedulerFactory
- org.apache.hadoop.hbase.master.MasterFileSystem - Class in org.apache.hadoop.hbase.master
-
This class abstracts a bunch of operations the HMaster needs to interact with the underlying file system like creating the initial layout, checking file system status, etc.
- MasterFileSystem(Configuration) - Constructor for class org.apache.hadoop.hbase.master.MasterFileSystem
- org.apache.hadoop.hbase.zookeeper.MasterMaintenanceModeTracker - Class in org.apache.hadoop.hbase.zookeeper
-
Tracks the master Maintenance Mode via ZK.
- MasterMaintenanceModeTracker(ZKWatcher) - Constructor for class org.apache.hadoop.hbase.zookeeper.MasterMaintenanceModeTracker
- masterMaintZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZNodePaths
- org.apache.hadoop.hbase.MasterNotRunningException - Exception in org.apache.hadoop.hbase
-
Thrown if the master is not running
- MasterNotRunningException() - Constructor for exception org.apache.hadoop.hbase.MasterNotRunningException
-
default constructor
- MasterNotRunningException(Exception) - Constructor for exception org.apache.hadoop.hbase.MasterNotRunningException
-
Constructor taking another exception.
- MasterNotRunningException(String) - Constructor for exception org.apache.hadoop.hbase.MasterNotRunningException
-
Constructor
- MasterNotRunningException(String, Exception) - Constructor for exception org.apache.hadoop.hbase.MasterNotRunningException
- org.apache.hadoop.hbase.coprocessor.MasterObserver - Interface in org.apache.hadoop.hbase.coprocessor
-
Defines coprocessor hooks for interacting with operations on the
HMaster
process. - org.apache.hadoop.hbase.quotas.MasterQuotaManager - Class in org.apache.hadoop.hbase.quotas
-
Master Quota Manager.
- MasterQuotaManager(MasterServices) - Constructor for class org.apache.hadoop.hbase.quotas.MasterQuotaManager
- org.apache.hadoop.hbase.quotas.MasterQuotasObserver - Class in org.apache.hadoop.hbase.quotas
-
An observer to automatically delete quotas when a table/namespace is deleted.
- MasterQuotasObserver() - Constructor for class org.apache.hadoop.hbase.quotas.MasterQuotasObserver
- org.apache.hadoop.hbase.master.MasterRegionServerList - Class in org.apache.hadoop.hbase.master
-
MasterRegion
basedRegionServerList
. - MasterRegionServerList(MasterRegion, Abortable) - Constructor for class org.apache.hadoop.hbase.master.MasterRegionServerList
- org.apache.hadoop.hbase.client.MasterRegistry - Class in org.apache.hadoop.hbase.client
-
Deprecated.Since 2.5.0, will be removed in 4.0.0. Use
RpcConnectionRegistry
instead. - org.apache.hadoop.hbase.exceptions.MasterRegistryFetchException - Exception in org.apache.hadoop.hbase.exceptions
-
Exception thrown when an master registry RPC fails in client.
- MasterRegistryFetchException(Set<ServerName>, Throwable) - Constructor for exception org.apache.hadoop.hbase.exceptions.MasterRegistryFetchException
- org.apache.hadoop.hbase.master.MasterRpcServices - Class in org.apache.hadoop.hbase.master
-
Implements the master RPC services.
- MasterRpcServices(HMaster) - Constructor for class org.apache.hadoop.hbase.master.MasterRpcServices
- org.apache.hadoop.hbase.master.MasterRpcServicesVersionWrapper - Class in org.apache.hadoop.hbase.master
-
A wrapper class for MasterRpcServices shortcut that ensures a client version is available to the callee without a current RPC call.
- MasterRpcServicesVersionWrapper(MasterRpcServices) - Constructor for class org.apache.hadoop.hbase.master.MasterRpcServicesVersionWrapper
- org.apache.hadoop.hbase.master.MasterRpcServicesVersionWrapper.ServiceCallFunction<Req,
Resp> - Interface in org.apache.hadoop.hbase.master - org.apache.hadoop.hbase.master.MasterServices - Interface in org.apache.hadoop.hbase.master
-
A curated subset of services provided by
HMaster
. - org.apache.hadoop.hbase.master.MasterStateStore - Class in org.apache.hadoop.hbase.master
-
A state storage which stores the state in master local region.
- MasterStateStore(MasterRegion, String, ZKWatcher, String) - Constructor for class org.apache.hadoop.hbase.master.MasterStateStore
- org.apache.hadoop.hbase.exceptions.MasterStoppedException - Exception in org.apache.hadoop.hbase.exceptions
-
Thrown when the master is stopped
- MasterStoppedException() - Constructor for exception org.apache.hadoop.hbase.exceptions.MasterStoppedException
- org.apache.hadoop.hbase.client.MasterSwitchType - Enum Class in org.apache.hadoop.hbase.client
-
Represents the master switch type
- MasterThread(HMaster, int) - Constructor for class org.apache.hadoop.hbase.util.JVMClusterUtil.MasterThread
- org.apache.hadoop.hbase.master.MasterWalManager - Class in org.apache.hadoop.hbase.master
-
This class abstracts a bunch of operations the HMaster needs when splitting log files e.g.
- MasterWalManager(Configuration, FileSystem, Path, MasterServices) - Constructor for class org.apache.hadoop.hbase.master.MasterWalManager
- MasterWalManager(MasterServices) - Constructor for class org.apache.hadoop.hbase.master.MasterWalManager
- match(ExtendedCell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.IncludeAllCompactionQueryMatcher
- match(ExtendedCell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.MajorCompactionScanQueryMatcher
- match(ExtendedCell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.MinorCompactionScanQueryMatcher
- match(ExtendedCell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.NormalUserScanQueryMatcher
- match(ExtendedCell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.RawScanQueryMatcher
- match(ExtendedCell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher
-
Determines if the caller should do one of several things: seek/skip to the next row (MatchCode.SEEK_NEXT_ROW) seek/skip to the next column (MatchCode.SEEK_NEXT_COL) include the current KeyValue (MatchCode.INCLUDE) ignore the current KeyValue (MatchCode.SKIP) got to the next row (MatchCode.DONE)
- match(ExtendedCell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.StripeCompactionScanQueryMatcher
- matchColumn(ExtendedCell, long, byte) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.UserScanQueryMatcher
- matchedColumn - Variable in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
- matches(String) - Method in enum class org.apache.hadoop.hbase.security.SaslUtil.QualityOfProtection
- matches(RegionState.State...) - Method in enum class org.apache.hadoop.hbase.master.RegionState.State
- MATCHINGCELLS - Enum constant in enum class org.apache.hadoop.hbase.mapreduce.SyncTable.SyncMapper.Counter
- matchingColumn(Cell, byte[], byte[]) - Static method in class org.apache.hadoop.hbase.CellUtil
- matchingColumn(Cell, byte[], int, int, byte[], int, int) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
- matchingColumn(Cell, Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
- matchingColumnFamilyAndQualifierPrefix(Cell, byte[], byte[]) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Returns True if matching column family and the qualifier starts with
qual
- matchingFamily(Cell, byte[]) - Static method in class org.apache.hadoop.hbase.CellUtil
- matchingFamily(Cell, byte[], int, int) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
- matchingFamily(Cell, byte, Cell, byte) - Static method in class org.apache.hadoop.hbase.CellUtil
- matchingFamily(Cell, Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
- matchingQualifier(Cell, byte[]) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Finds if the qualifier part of the cell and the KV serialized byte[] are equal.
- matchingQualifier(Cell, byte[], int, int) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
Finds if the qualifier part of the cell and the KV serialized byte[] are equal
- matchingQualifier(Cell, Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
- matchingRow(Cell, byte[], int, int) - Static method in class org.apache.hadoop.hbase.CellUtil
- matchingRowColumn(Cell, Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Compares the row and column of two keyvalues for equality
- matchingRowColumnBytes(Cell, Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Compares the row and column of two keyvalues for equality
- matchingRows(Cell, byte[]) - Static method in class org.apache.hadoop.hbase.CellUtil
- matchingRows(Cell, byte[], int, int) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
- matchingRows(Cell, short, Cell, short) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Compares the row of two keyvalues for equality
- matchingRows(Cell, Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Compares the row of two keyvalues for equality
- MATCHINGROWS - Enum constant in enum class org.apache.hadoop.hbase.mapreduce.SyncTable.SyncMapper.Counter
- matchingTags(Cell, Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Deprecated.Since 3.0.0, will be removed in 4.0.0. Tags are now internal only, you should not try to check it through the
Cell
interface. - matchingTags(ExtendedCell, ExtendedCell) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
- matchingTags(ExtendedCell, ExtendedCell, int, int) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
- matchingTimestamp(Cell, Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
- matchingType(ExtendedCell, ExtendedCell) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
- matchingValue(Cell, byte[]) - Static method in class org.apache.hadoop.hbase.CellUtil
- matchingValue(Cell, Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
- matchingValue(Cell, Cell, int, int) - Static method in class org.apache.hadoop.hbase.CellUtil
- matchingValue(Cell, Cell, int, int) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
- matchingValue(Tag, Tag) - Static method in interface org.apache.hadoop.hbase.Tag
-
Matches the value part of given tags
- matchReplicationScope(boolean) - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
Check if the table's cfs' replication scope matched with the replication state
- MAX_ALLOC_DEFAULT - Static variable in interface org.apache.hadoop.hbase.regionserver.MemStoreLAB
- MAX_ALLOC_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MemStoreLAB
- MAX_ATTEMPTS_FN_GENERATION - Static variable in class org.apache.hadoop.hbase.favored.FavoredNodeAssignmentHelper
- MAX_ATTEMPTS_KEY - Static variable in class org.apache.hadoop.hbase.namequeues.WALEventTrackerTableAccessor
- MAX_AVERAGE_REGION_SIZE - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
In auto-balance, we split input by ave region size, if calculated region size is too big, we can set it.
- MAX_BACKOFF_KEY - Static variable in class org.apache.hadoop.hbase.client.backoff.ExponentialClientBackoffPolicy
- MAX_BLOCK_SIZE_UNCOMPRESSED - Static variable in interface org.apache.hadoop.hbase.io.hfile.BlockCompressedSizePredicator
- MAX_BUFFER_COUNT_KEY - Static variable in class org.apache.hadoop.hbase.io.ByteBuffAllocator
- MAX_CHUNK_SIZE_KEY - Static variable in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex
-
The maximum size guideline for index blocks (both leaf, intermediate, and root).
- MAX_CLOCK_SKEW_MS - Static variable in class org.apache.hadoop.hbase.master.ServerManager
- MAX_COMPACTED_STORE_FILE_REF_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- MAX_COMPACTION_QUEUE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
- MAX_COMPACTION_QUEUE_SIZE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
- MAX_FILES_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.StripeStoreConfig
-
The maximum number of files to compact within a stripe; same as for regular compaction.
- MAX_FILESIZE - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
Used by HBase Shell interface to access this metadata attribute which denotes the maximum size of the store file after which a region split occurs.
- MAX_FLUSH_PER_CHANGES - Static variable in class org.apache.hadoop.hbase.regionserver.HRegion
-
The following MAX_FLUSH_PER_CHANGES is large enough because each KeyValue has 20+ bytes overhead.
- MAX_FLUSH_QUEUE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
- MAX_FLUSH_QUEUE_SIZE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
- MAX_FORMAT_VERSION - Static variable in class org.apache.hadoop.hbase.io.hfile.HFile
-
Maximum supported HFile format version
- MAX_FRAME_SIZE_CONF_DEFAULT - Static variable in class org.apache.hadoop.hbase.thrift.Constants
- MAX_FRAME_SIZE_CONF_KEY - Static variable in class org.apache.hadoop.hbase.thrift.Constants
- MAX_HEAP_SIZE - Enum constant in enum class org.apache.hadoop.hbase.hbtop.field.Field
- MAX_IDLETIME - Static variable in class org.apache.hadoop.hbase.rest.RESTServlet
- MAX_IDLETIME - Static variable in class org.apache.hadoop.hbase.thrift.HBaseServiceHandler
- MAX_KEYVALUE_SIZE_DEFAULT - Static variable in class org.apache.hadoop.hbase.client.ConnectionConfiguration
- MAX_KEYVALUE_SIZE_KEY - Static variable in class org.apache.hadoop.hbase.client.ConnectionConfiguration
- MAX_LOGS - Static variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
- MAX_MEMSTORE_TS_KEY - Static variable in interface org.apache.hadoop.hbase.io.hfile.HFile.Writer
-
Max memstore (mvcc) timestamp in FileInfo
- MAX_METRIC_NAME - Static variable in interface org.apache.hadoop.metrics2.MetricHistogram
- MAX_OUTBOUND_BYTES_EXCEEDED_DESC - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
- MAX_OUTBOUND_BYTES_EXCEEDED_NAME - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
- MAX_PENDING_SIZE - Static variable in class org.apache.hadoop.hbase.regionserver.regionreplication.RegionReplicationBufferManager
-
This is the total size of pending entries for all the sinks.
- MAX_PENDING_SIZE_DEFAULT - Static variable in class org.apache.hadoop.hbase.regionserver.regionreplication.RegionReplicationBufferManager
- MAX_PRECISION - Static variable in class org.apache.hadoop.hbase.util.OrderedBytes
-
Max precision guaranteed to fit into a
long
. - MAX_QUEUE_SIZE_OPTION - Static variable in class org.apache.hadoop.hbase.thrift.Constants
- MAX_QUEUED_REQUESTS_CONF_KEY - Static variable in class org.apache.hadoop.hbase.thrift.TBoundedThreadPoolServer
-
The maximum number of pending connections waiting in the queue.
- MAX_REGION_SPLIT_IMBALANCE_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.StripeStoreConfig
-
When splitting region, the maximum size imbalance to allow in an attempt to split at a stripe boundary, so that no files go to both regions.
- MAX_REQUEST_SIZE - Static variable in class org.apache.hadoop.hbase.ipc.RpcServer
- MAX_ROW_LENGTH - Static variable in class org.apache.hadoop.hbase.HConstants
-
Max length a row can have because of the limitation in TFile.
- MAX_SEQ_ID_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.HStoreFile
-
Max Sequence ID in FileInfo
- MAX_SERVER_PER_MESSAGE - Static variable in class org.apache.hadoop.hbase.master.ClusterStatusPublisher
-
We want to limit the size of the protobuf message sent, do fit into a single packet.
- MAX_SIZE - Static variable in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
- MAX_SLEEP_TIME_KEY - Static variable in class org.apache.hadoop.hbase.namequeues.WALEventTrackerTableAccessor
- MAX_STORE_FILE_AGE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- MAX_STORE_FILE_AGE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- MAX_STOREFILE_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- MAX_STOREFILE_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- MAX_TAG_LENGTH - Static variable in interface org.apache.hadoop.hbase.Tag
- MAX_TAGS_LEN - Static variable in class org.apache.hadoop.hbase.io.hfile.HFileInfo
- MAX_TAGS_LENGTH - Static variable in interface org.apache.hadoop.hbase.RawCell
- MAX_TIME - Static variable in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
- MAX_TYPE - Static variable in class org.apache.hadoop.hbase.util.CellHashKey
- MAX_VERSIONS - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
- MAX_WORKER_THREADS_CONF_KEY - Static variable in class org.apache.hadoop.hbase.thrift.TBoundedThreadPoolServer
-
The maximum size of the thread pool.
- MAX_WORKERS_OPTION - Static variable in class org.apache.hadoop.hbase.thrift.Constants
- maxCellIdx - Variable in class org.apache.hadoop.hbase.regionserver.CellFlatMap
- maxColDataSize - Variable in class org.apache.hadoop.hbase.util.LoadTestTool
- maxColsPerKey - Variable in class org.apache.hadoop.hbase.util.LoadTestTool
- maxColumn - Variable in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
- maxColumnInclusive - Variable in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
- maxHeapUsage - Variable in class org.apache.hadoop.hbase.wal.BoundedEntryBuffers
- Maximum - Enum constant in enum class org.apache.hadoop.hbase.KeyValue.Type
- MAXIMUM_KEY_LENGTH - Static variable in class org.apache.hadoop.hbase.io.hfile.HFile
-
Maximum length of key in HFile.
- MAXIMUM_VALUE_LENGTH - Static variable in class org.apache.hadoop.hbase.HConstants
-
Maximum value length, enforced on KeyValue construction
- maxKeyCount() - Method in class org.apache.hadoop.hbase.regionserver.CreateStoreFileWriterParams
- maxKeyCount(long) - Method in class org.apache.hadoop.hbase.regionserver.CreateStoreFileWriterParams
- maxKeys - Variable in class org.apache.hadoop.hbase.util.BloomFilterChunk
-
Max Keys expected for the bloom
- maxKeyValueSize(int) - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
-
Override the maximum key-value size specified by the provided
Connection
'sConfiguration
instance, via the configuration keyhbase.client.keyvalue.maxsize
. - maxLogs - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
- maxMemstoreTS - Variable in class org.apache.hadoop.hbase.io.hfile.HFileWriterImpl
- maxOutboundBytesExceeded() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
- maxOutboundBytesExceeded() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceImpl
- maxQueueLength - Variable in class org.apache.hadoop.hbase.ipc.FifoRpcScheduler
- maxQueueLength - Variable in class org.apache.hadoop.hbase.ipc.PluggableBlockingQueue
- maxQueueSizeInBytes - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
-
Maximum size in bytes of the currently queued and running Calls.
- maxReadPointToTrackVersions - Variable in class org.apache.hadoop.hbase.regionserver.querymatcher.CompactionScanQueryMatcher
-
readPoint over which the KVs are unconditionally included
- maxRequestSize - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
- maxRetries - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
- maxthreads(int) - Method in class org.apache.hadoop.hbase.util.RegionMover.RegionMoverBuilder
-
Set the max number of threads that will be used to move regions
- maxThroughputLowerBound - Variable in class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareThroughputController
- maxThroughputUpperBound - Variable in class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareThroughputController
- maxVersions - Variable in class org.apache.hadoop.hbase.regionserver.querymatcher.NewVersionBehaviorTracker
- maybeCloneWithAllocator(ExtendedCell, boolean) - Method in class org.apache.hadoop.hbase.regionserver.CompositeImmutableSegment
-
If the segment has a memory allocator the cell is being cloned to this space, and returned; otherwise the given cell is returned
- maybeCloneWithAllocator(ExtendedCell, boolean) - Method in class org.apache.hadoop.hbase.regionserver.Segment
-
If the segment has a memory allocator the cell is being cloned to this space, and returned; otherwise the given cell is returned When a cell's size is too big (bigger than maxAlloc), it is not allocated on MSLAB.
- mayHaveClusterIssues() - Method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
- mayHaveMoreCellsInRow() - Method in class org.apache.hadoop.hbase.client.Result
-
For scanning large rows, the RS may choose to return the cells chunk by chunk to prevent OOM or timeout.
- MB_IN_BYTES - Static variable in class org.apache.hadoop.hbase.HConstants
- mBeanServer - Variable in class org.apache.hadoop.hbase.http.jmx.JMXJsonServlet
-
MBean server.
- org.apache.hadoop.hbase.metrics.MBeanSource - Interface in org.apache.hadoop.hbase.metrics
-
Object that will register an mbean with the underlying metrics implementation.
- org.apache.hadoop.hbase.metrics.MBeanSourceImpl - Class in org.apache.hadoop.hbase.metrics
-
Hadoop2 metrics2 implementation of an object that registers MBeans.
- MBeanSourceImpl() - Constructor for class org.apache.hadoop.hbase.metrics.MBeanSourceImpl
- md - Variable in class org.apache.hadoop.hbase.ipc.ServerCall
- MD5_HEX_LENGTH - Static variable in interface org.apache.hadoop.hbase.client.RegionInfo
- org.apache.hadoop.hbase.util.MD5Hash - Class in org.apache.hadoop.hbase.util
-
Utility class for MD5 MD5 hash produces a 128-bit digest.
- MD5Hash() - Constructor for class org.apache.hadoop.hbase.util.MD5Hash
- md5PrefixedKey(long) - Static method in class org.apache.hadoop.hbase.util.LoadTestKVGenerator
-
Converts the given key to string, and prefixes it with the MD5 hash of the index's string representation.
- MEAN_METRIC_NAME - Static variable in interface org.apache.hadoop.metrics2.MetricHistogram
- measure() - Method in interface org.apache.hadoop.hbase.util.TimeMeasurable
-
Measure elapsed time.
- measure(TimeMeasurable<T>) - Method in class org.apache.hadoop.hbase.util.MovingAverage
-
Measure elapsed time of a measurable method.
- mechanismName - Variable in enum class org.apache.hadoop.hbase.security.AuthMethod
- MEDIAN_METRIC_NAME - Static variable in interface org.apache.hadoop.metrics2.MetricHistogram
- MEGABYTE - Enum constant in enum class org.apache.hadoop.hbase.Size.Unit
- MEM_STORE_SIZE - Enum constant in enum class org.apache.hadoop.hbase.hbtop.field.Field
- MEMCACHED_CONFIG_KEY - Static variable in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
- MEMCACHED_DEFAULT_TIMEOUT - Static variable in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
- MEMCACHED_OPTIMEOUT_KEY - Static variable in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
- MEMCACHED_OPTIMIZE_DEFAULT - Static variable in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
- MEMCACHED_OPTIMIZE_KEY - Static variable in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
- MEMCACHED_TIMEOUT_KEY - Static variable in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
- org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache - Class in org.apache.hadoop.hbase.io.hfile
-
Class to store blocks into memcached.
- MemcachedBlockCache(Configuration) - Constructor for class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
- MEMORY - Enum constant in enum class org.apache.hadoop.hbase.io.hfile.BlockPriority
-
Block from in-memory store
- org.apache.hadoop.hbase.MemoryCompactionPolicy - Enum Class in org.apache.hadoop.hbase
-
Enum describing all possible memory compaction policies
- org.apache.hadoop.hbase.io.util.MemorySizeUtil - Class in org.apache.hadoop.hbase.io.util
-
Util class to calculate memory size for memstore(on heap, off heap), block cache(L1, L2) of RS.
- MemorySizeUtil() - Constructor for class org.apache.hadoop.hbase.io.util.MemorySizeUtil
- memstore - Variable in class org.apache.hadoop.hbase.regionserver.HStore
- org.apache.hadoop.hbase.regionserver.MemStore - Interface in org.apache.hadoop.hbase.regionserver
-
The MemStore holds in-memory modifications to the Store.
- MEMSTORE_CLASS_NAME - Static variable in class org.apache.hadoop.hbase.regionserver.HStore
- MEMSTORE_FLUSH_PER_CHANGES - Static variable in class org.apache.hadoop.hbase.regionserver.HRegion
-
Conf key to force a flush if there are already enough changes for one region in memstore
- MEMSTORE_FLUSHSIZE - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
Used by HBase Shell interface to access this metadata attribute which represents the maximum size of the memstore after which its contents are flushed onto the disk.
- MEMSTORE_HEAP_SIZE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- MEMSTORE_HEAP_SIZE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- MEMSTORE_OFFHEAP_SIZE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- MEMSTORE_OFFHEAP_SIZE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- MEMSTORE_OFFHEAP_SIZE_GAUGE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSource
- MEMSTORE_OFFHEAP_SIZE_GAUGE_NAME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSource
- MEMSTORE_ONHEAP_SIZE_GAUGE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSource
- MEMSTORE_ONHEAP_SIZE_GAUGE_NAME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSource
- MEMSTORE_PERIODIC_FLUSH_INTERVAL - Static variable in class org.apache.hadoop.hbase.regionserver.HRegion
-
Conf key for the periodic flush interval
- MEMSTORE_SIZE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- MEMSTORE_SIZE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- MEMSTORE_SIZE_GAUGE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSource
- MEMSTORE_SIZE_GAUGE_NAME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSource
- MEMSTORE_SIZE_KEY - Static variable in class org.apache.hadoop.hbase.io.util.MemorySizeUtil
- MEMSTORE_SIZE_LOWER_LIMIT_KEY - Static variable in class org.apache.hadoop.hbase.io.util.MemorySizeUtil
- MEMSTORE_SIZE_LOWER_LIMIT_OLD_KEY - Static variable in class org.apache.hadoop.hbase.io.util.MemorySizeUtil
- MEMSTORE_SIZE_MAX_RANGE_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager
- MEMSTORE_SIZE_MIN_RANGE_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager
- MEMSTORE_SIZE_OLD_KEY - Static variable in class org.apache.hadoop.hbase.io.util.MemorySizeUtil
- org.apache.hadoop.hbase.regionserver.MemStoreCompactionStrategy - Class in org.apache.hadoop.hbase.regionserver
-
MemStoreCompactionStrategy is the root of a class hierarchy which defines the strategy for choosing the next action to apply in an (in-memory) memstore compaction.
- MemStoreCompactionStrategy(Configuration, String) - Constructor for class org.apache.hadoop.hbase.regionserver.MemStoreCompactionStrategy
- org.apache.hadoop.hbase.regionserver.MemStoreCompactionStrategy.Action - Enum Class in org.apache.hadoop.hbase.regionserver
-
Types of actions to be done on the pipeline upon MemStoreCompaction invocation.
- org.apache.hadoop.hbase.regionserver.MemStoreCompactor - Class in org.apache.hadoop.hbase.regionserver
-
The ongoing MemStore Compaction manager, dispatches a solo running compaction and interrupts the compaction if requested.
- MemStoreCompactor(CompactingMemStore, MemoryCompactionPolicy) - Constructor for class org.apache.hadoop.hbase.regionserver.MemStoreCompactor
- org.apache.hadoop.hbase.regionserver.MemStoreCompactorSegmentsIterator - Class in org.apache.hadoop.hbase.regionserver
-
The MemStoreCompactorSegmentsIterator extends MemStoreSegmentsIterator and performs the scan for compaction operation meaning it is based on SQM
- MemStoreCompactorSegmentsIterator(List<ImmutableSegment>, CellComparator, int, HStore) - Constructor for class org.apache.hadoop.hbase.regionserver.MemStoreCompactorSegmentsIterator
- org.apache.hadoop.hbase.regionserver.MemStoreFlusher - Class in org.apache.hadoop.hbase.regionserver
-
Thread that flushes cache on request NOTE: This class extends Thread rather than Chore because the sleep time can be interrupted when there is something to do, rather than the Chore sleep time which is invariant.
- MemStoreFlusher(Configuration, HRegionServer) - Constructor for class org.apache.hadoop.hbase.regionserver.MemStoreFlusher
- org.apache.hadoop.hbase.regionserver.MemStoreLAB - Interface in org.apache.hadoop.hbase.regionserver
-
A memstore-local allocation buffer.
- org.apache.hadoop.hbase.regionserver.MemStoreLABImpl - Class in org.apache.hadoop.hbase.regionserver
-
A memstore-local allocation buffer.
- MemStoreLABImpl() - Constructor for class org.apache.hadoop.hbase.regionserver.MemStoreLABImpl
- MemStoreLABImpl(Configuration) - Constructor for class org.apache.hadoop.hbase.regionserver.MemStoreLABImpl
- org.apache.hadoop.hbase.regionserver.MemStoreMergerSegmentsIterator - Class in org.apache.hadoop.hbase.regionserver
-
The MemStoreMergerSegmentsIterator extends MemStoreSegmentsIterator and performs the scan for simple merge operation meaning it is NOT based on SQM
- MemStoreMergerSegmentsIterator(List<ImmutableSegment>, CellComparator, int) - Constructor for class org.apache.hadoop.hbase.regionserver.MemStoreMergerSegmentsIterator
- org.apache.hadoop.hbase.regionserver.MemStoreSegmentsIterator - Class in org.apache.hadoop.hbase.regionserver
-
The MemStoreSegmentsIterator is designed to perform one iteration over given list of segments For another iteration new instance of MemStoreSegmentsIterator needs to be created The iterator is not thread-safe and must have only one instance per MemStore in each period of time
- MemStoreSegmentsIterator(int) - Constructor for class org.apache.hadoop.hbase.regionserver.MemStoreSegmentsIterator
- org.apache.hadoop.hbase.regionserver.MemStoreSize - Class in org.apache.hadoop.hbase.regionserver
-
Data structure of three longs.
- memStoreSizing - Variable in class org.apache.hadoop.hbase.regionserver.Segment
- org.apache.hadoop.hbase.regionserver.MemStoreSizing - Interface in org.apache.hadoop.hbase.regionserver
-
Accounting of current heap and data sizes.
- org.apache.hadoop.hbase.regionserver.MemStoreSnapshot - Class in org.apache.hadoop.hbase.regionserver
-
MemStoreSnapshot
is a Context Object to hold details of the snapshot taken on a MemStore. - MemStoreSnapshot(long, ImmutableSegment) - Constructor for class org.apache.hadoop.hbase.regionserver.MemStoreSnapshot
- MEMSTORETS_TAGS_PARAMETRIZED - Static variable in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.This is for unit tests parameterized with a single boolean.
- memStoreTSTagsAndOffheapCombination() - Static method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- merge(Configuration, Configuration) - Static method in class org.apache.hadoop.hbase.HBaseConfiguration
-
Merge two configurations.
- merge(QuotaSettings) - Method in class org.apache.hadoop.hbase.quotas.GlobalQuotaSettingsImpl
- merge(QuotaSettings) - Method in class org.apache.hadoop.hbase.quotas.ThrottleSettings
- MERGE - Enum constant in enum class org.apache.hadoop.hbase.backup.BackupRestoreConstants.BackupCommand
- MERGE - Enum constant in enum class org.apache.hadoop.hbase.client.MasterSwitchType
- MERGE - Enum constant in enum class org.apache.hadoop.hbase.regionserver.MemStoreCompactionStrategy.Action
- MERGE_COUNT_UNIQUE_KEYS - Enum constant in enum class org.apache.hadoop.hbase.regionserver.MemStoreCompactionStrategy.Action
- MERGE_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 merge enabled.
- MERGE_METRIC_PREFIX - Static variable in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
- MERGE_PLAN_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
- MERGE_PLAN_COUNT_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
- MERGE_QUALIFIER_PREFIX - Static variable in class org.apache.hadoop.hbase.HConstants
- MERGE_QUALIFIER_PREFIX_STR - Static variable in class org.apache.hadoop.hbase.HConstants
-
Merge qualifier prefix.
- MERGE_REGION - Enum constant in enum class org.apache.hadoop.hbase.regionserver.Region.Operation
- MERGEA_QUALIFIER - Static variable in class org.apache.hadoop.hbase.HConstants
-
Deprecated.Since 2.3.0 and 2.2.1. Not used anymore. Instead we look for the
HConstants.MERGE_QUALIFIER_PREFIX_STR
prefix. - MERGEB_QUALIFIER - Static variable in class org.apache.hadoop.hbase.HConstants
-
Deprecated.Since 2.3.0 and 2.2.1. Not used anymore. Instead we look for the
HConstants.MERGE_QUALIFIER_PREFIX_STR
prefix. - mergeBackups(String[]) - Method in interface org.apache.hadoop.hbase.backup.BackupAdmin
-
Merge backup images command
- MERGED - Enum constant in enum class org.apache.hadoop.hbase.master.RegionState.State
- mergeDelimitedFrom(Message.Builder, InputStream) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
This version of protobuf's mergeDelimitedFrom avoid the hard-coded 64MB limit for decoding buffers
- mergeFrom(Message.Builder, byte[]) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
This version of protobuf's mergeFrom avoids the hard-coded 64MB limit for decoding buffers when working with byte arrays
- mergeFrom(Message.Builder, byte[], int, int) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
This version of protobuf's mergeFrom avoids the hard-coded 64MB limit for decoding buffers when working with byte arrays
- mergeFrom(Message.Builder, InputStream) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
This version of protobuf's mergeFrom avoids the hard-coded 64MB limit for decoding buffers where the message size is not known
- mergeFrom(Message.Builder, InputStream, int) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
This version of protobuf's mergeFrom avoids the hard-coded 64MB limit for decoding buffers where the message size is known
- mergeFrom(Message.Builder, ByteString) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
This version of protobuf's mergeFrom avoids the hard-coded 64MB limit for decoding buffers when working with ByteStrings
- mergeFrom(Message.Builder, CodedInputStream) - Static method in class org.apache.hadoop.hbase.rest.RestUtil
-
Merges the object from codedInput, then calls checkLastTagWas.
- mergeFrom(Message.Builder, CodedInputStream, int) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
- mergeLocations(RegionLocations) - Method in class org.apache.hadoop.hbase.RegionLocations
-
Merges this RegionLocations list with the given list assuming same range, and keeping the most up to date version of the HRegionLocation entries from either list according to seqNum.
- mergeRegionDirs(Path, HbckRegionInfo) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.Merge hdfs data by moving from contained HbckRegionInfo into targetRegionDir.
- org.apache.hadoop.hbase.exceptions.MergeRegionException - Exception in org.apache.hadoop.hbase.exceptions
-
Thrown when something is wrong in trying to merge two regions.
- MergeRegionException() - Constructor for exception org.apache.hadoop.hbase.exceptions.MergeRegionException
-
default constructor
- MergeRegionException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.MergeRegionException
-
Constructor
- MergeRegionException(Throwable) - Constructor for exception org.apache.hadoop.hbase.exceptions.MergeRegionException
- mergeRegions(byte[], byte[], boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Deprecated.since 2.3.0 and will be removed in 4.0.0.Use
AsyncAdmin.mergeRegions(List, boolean)
instead. - mergeRegions(List<byte[]>, boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Merge multiple regions (>=2).
- mergeRegions(RegionInfo[], boolean, long, long) - Method in class org.apache.hadoop.hbase.master.HMaster
- mergeRegions(RegionInfo[], boolean, long, long) - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Merge regions in a table.
- mergeRegionsAsync(byte[][], boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Merge multiple regions (>=2).
- mergeRegionsAsync(byte[], byte[], boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Deprecated.since 2.3.0 and will be removed in 4.0.0. Multi-region merge feature is now supported. Use
Admin.mergeRegionsAsync(byte[][], boolean)
instead. - mergeStoreFile(RegionInfo, String, HStoreFile, StoreFileTracker) - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
Write out a merge reference under the given merges directory.
- mergeSwitch(boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Turn the Merge switch on or off.
- mergeSwitch(boolean, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Turn the merge switch on or off.
- mergeSwitch(boolean, boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Turn the Merge switch on or off.
- mergeTableRegions(RpcController, MasterProtos.MergeTableRegionsRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- MERGING - Enum constant in enum class org.apache.hadoop.hbase.master.RegionState.State
- MERGING_NEW - Enum constant in enum class org.apache.hadoop.hbase.master.RegionState.State
- org.apache.hadoop.hbase.codec.MessageCodec - Class in org.apache.hadoop.hbase.codec
-
Codec that just writes out Cell as a protobuf Cell Message.
- MessageCodec() - Constructor for class org.apache.hadoop.hbase.codec.MessageCodec
- messageFromObject() - Method in interface org.apache.hadoop.hbase.rest.ProtobufMessageHandler
-
Convert to model to a protobuf Message object
- org.apache.hadoop.hbase.hbtop.screen.top.MessageModeScreenPresenter - Class in org.apache.hadoop.hbase.hbtop.screen.top
-
The presentation logic for the message mode.
- MessageModeScreenPresenter(MessageModeScreenView, String, ScreenView) - Constructor for class org.apache.hadoop.hbase.hbtop.screen.top.MessageModeScreenPresenter
- org.apache.hadoop.hbase.hbtop.screen.top.MessageModeScreenView - Class in org.apache.hadoop.hbase.hbtop.screen.top
-
The message mode in the top screen.
- MessageModeScreenView(Screen, Terminal, int, String, ScreenView) - Constructor for class org.apache.hadoop.hbase.hbtop.screen.top.MessageModeScreenView
- META - Enum constant in enum class org.apache.hadoop.hbase.io.hfile.BlockType.BlockCategory
- META - Enum constant in enum class org.apache.hadoop.hbase.io.hfile.BlockType
-
Meta blocks
- META_CALL_QUEUE_READ_SHARE_CONF_KEY - Static variable in class org.apache.hadoop.hbase.ipc.MetaRWQueueRpcExecutor
- META_CALL_QUEUE_SCAN_SHARE_CONF_KEY - Static variable in class org.apache.hadoop.hbase.ipc.MetaRWQueueRpcExecutor
- META_COMPARATOR - Static variable in class org.apache.hadoop.hbase.MetaCellComparator
-
A
MetaCellComparator
forhbase:meta
catalog tableKeyValue
s. - META_EDIT_OPERATION_TIMEOUT_MS - Static variable in class org.apache.hadoop.hbase.regionserver.regionreplication.RegionReplicationSink
- META_EDIT_OPERATION_TIMEOUT_MS_DEFAULT - Static variable in class org.apache.hadoop.hbase.regionserver.regionreplication.RegionReplicationSink
- META_EDIT_RPC_TIMEOUT_MS - Static variable in class org.apache.hadoop.hbase.regionserver.regionreplication.RegionReplicationSink
- META_EDIT_RPC_TIMEOUT_MS_DEFAULT - Static variable in class org.apache.hadoop.hbase.regionserver.regionreplication.RegionReplicationSink
- META_REPLICAS_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.
- META_ROW_DELIMITER - Static variable in class org.apache.hadoop.hbase.HConstants
-
delimiter used between portions of a region name
- META_SPLIT_SIZE_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterFileSystemSource
- META_SPLIT_SIZE_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterFileSystemSource
- META_SPLIT_TIME_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterFileSystemSource
- META_SPLIT_TIME_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterFileSystemSource
- META_TABLE_NAME - Static variable in class org.apache.hadoop.hbase.TableName
-
The hbase:meta table's name.
- META_TRANSITION_QOS - Static variable in class org.apache.hadoop.hbase.master.MasterAnnotationReadingPriorityFunction
-
We reference this value in SimpleRpcScheduler so this class have to be public instead of package private
- META_VERSION - Static variable in class org.apache.hadoop.hbase.HConstants
-
The current version of the meta table.
- META_VERSION_QUALIFIER - Static variable in class org.apache.hadoop.hbase.HConstants
-
The meta table version column qualifier.
- META_WAL_PROVIDER - Static variable in class org.apache.hadoop.hbase.wal.WALFactory
- META_WAL_PROVIDER_ID - Static variable in class org.apache.hadoop.hbase.wal.AbstractFSWALProvider
-
The hbase:meta region's WAL filename extension
- META_ZNODE_PREFIX - Static variable in class org.apache.hadoop.hbase.zookeeper.ZNodePaths
- META_ZNODE_PREFIX_CONF_KEY - Static variable in class org.apache.hadoop.hbase.zookeeper.ZNodePaths
- metaBlockIndexReader - Variable in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
-
Meta block index reader -- always single level
- org.apache.hadoop.hbase.MetaCellComparator - Class in org.apache.hadoop.hbase
-
A
CellComparatorImpl
forhbase:meta
catalog tableKeyValue
s. - MetaCellComparator() - Constructor for class org.apache.hadoop.hbase.MetaCellComparator
- metaData - Variable in class org.apache.hadoop.hbase.io.hfile.HFileWriterImpl
-
Writable
s representing meta block data. - METADATA - Static variable in class org.apache.hadoop.hbase.HConstants
- MetaEntry(RegionInfo, ServerName, long) - Constructor for class org.apache.hadoop.hbase.util.HbckRegionInfo.MetaEntry
- MetaEntry(RegionInfo, ServerName, long, RegionInfo, RegionInfo) - Constructor for class org.apache.hadoop.hbase.util.HbckRegionInfo.MetaEntry
- METAFAMILY - Static variable in class org.apache.hadoop.hbase.wal.WALEdit
- org.apache.hadoop.hbase.MetaMutationAnnotation - Annotation Interface in org.apache.hadoop.hbase
-
The field or the parameter to which this annotation can be applied only when it holds mutations for hbase:meta table.
- metaNames - Variable in class org.apache.hadoop.hbase.io.hfile.HFileWriterImpl
-
Meta block names.
- METAPRIORITY_QUEUE_DESC - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
- METAPRIORITY_QUEUE_NAME - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
- metaRegionExists(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Checks if meta region exists
- metaRegionLocationCache - Variable in class org.apache.hadoop.hbase.HBaseServerBase
-
Cache for the meta region replica's locations.
- org.apache.hadoop.hbase.MetaRegionLocationCache - Class in org.apache.hadoop.hbase
-
A cache of meta region location metadata.
- MetaRegionLocationCache(ZKWatcher) - Constructor for class org.apache.hadoop.hbase.MetaRegionLocationCache
- METAROW - Static variable in class org.apache.hadoop.hbase.wal.WALEdit
-
Deprecated.Since 2.3.0. Not used.
- org.apache.hadoop.hbase.ipc.MetaRWQueueRpcExecutor - Class in org.apache.hadoop.hbase.ipc
-
RPC Executor that uses different queues for reads and writes for meta.
- MetaRWQueueRpcExecutor(String, int, int, PriorityFunction, Configuration, Abortable) - Constructor for class org.apache.hadoop.hbase.ipc.MetaRWQueueRpcExecutor
- org.apache.hadoop.hbase.MetaTableAccessor - Class in org.apache.hadoop.hbase
-
Read/write operations on
hbase:meta
region as well as assignment information stored tohbase:meta
. - org.apache.hadoop.hbase.zookeeper.MetaTableLocator - Class in org.apache.hadoop.hbase.zookeeper
-
Utility class to perform operation (get/wait for/verify/set/delete) on znode in ZooKeeper which keeps hbase:meta region server location.
- org.apache.hadoop.hbase.coprocessor.MetaTableMetrics - Class in org.apache.hadoop.hbase.coprocessor
-
A coprocessor that collects metrics from meta table.
- MetaTableMetrics() - Constructor for class org.apache.hadoop.hbase.coprocessor.MetaTableMetrics
- meter(String) - Method in interface org.apache.hadoop.hbase.metrics.MetricRegistry
-
Get or construct a
Meter
used to measure durations and report distributions (a combination of aTimer
and aHistogram
. - org.apache.hadoop.hbase.metrics.Meter - Interface in org.apache.hadoop.hbase.metrics
-
A metric which measure the rate at which some operation is invoked.
- org.apache.hadoop.hbase.util.Methods - Class in org.apache.hadoop.hbase.util
- org.apache.hadoop.hbase.metrics.Metric - Interface in org.apache.hadoop.hbase.metrics
-
Parent interface for all metrics.
- METRIC_SERVLETS_CONF_KEY - Static variable in class org.apache.hadoop.hbase.http.HttpServer
- METRIC_USER_ENABLED_CONF - Static variable in class org.apache.hadoop.hbase.regionserver.MetricsUserAggregateFactory
- org.apache.hadoop.metrics2.MetricHistogram - Interface in org.apache.hadoop.metrics2
-
Metrics Histogram interface.
- org.apache.hadoop.hbase.metrics.MetricRegistries - Class in org.apache.hadoop.hbase.metrics
-
MetricRegistries is collection of MetricRegistry's.
- MetricRegistries() - Constructor for class org.apache.hadoop.hbase.metrics.MetricRegistries
- org.apache.hadoop.hbase.metrics.MetricRegistriesLoader - Class in org.apache.hadoop.hbase.metrics
- org.apache.hadoop.hbase.metrics.MetricRegistry - Interface in org.apache.hadoop.hbase.metrics
-
General purpose factory for creating various metrics.
- org.apache.hadoop.hbase.metrics.MetricRegistryFactory - Interface in org.apache.hadoop.hbase.metrics
-
A Factory for creating MetricRegistries.
- org.apache.hadoop.hbase.metrics.MetricRegistryInfo - Class in org.apache.hadoop.hbase.metrics
-
HBase Metrics are grouped in different MetricRegistry'ies.
- MetricRegistryInfo(String, String, String, String, boolean) - Constructor for class org.apache.hadoop.hbase.metrics.MetricRegistryInfo
- metrics - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
- metrics - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
- metrics - Variable in class org.apache.hadoop.hbase.thrift.HBaseServiceHandler
- metrics - Variable in class org.apache.hadoop.hbase.thrift.ThriftServer
- METRICS_CONTEXT - Static variable in interface org.apache.hadoop.hbase.io.MetricsIOSource
-
The name of the metrics context that metrics will be under.
- METRICS_CONTEXT - Static variable in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
-
The context metrics will be under.
- METRICS_CONTEXT - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterFileSystemSource
-
The context metrics will be under.
- METRICS_CONTEXT - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterProcSource
-
The context metrics will be under.
- METRICS_CONTEXT - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterQuotaSource
- METRICS_CONTEXT - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
-
The context metrics will be under.
- METRICS_CONTEXT - Static variable in interface org.apache.hadoop.hbase.master.MetricsSnapshotSource
-
The context metrics will be under.
- METRICS_CONTEXT - Static variable in interface org.apache.hadoop.hbase.namequeues.MetricsWALEventTrackerSource
-
The name of the metrics context that metrics will be under.
- METRICS_CONTEXT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSource
-
The name of the metrics context that metrics will be under.
- METRICS_CONTEXT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionAggregateSource
-
The name of the metrics context that metrics will be under.
- METRICS_CONTEXT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerQuotaSource
- METRICS_CONTEXT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
The name of the metrics context that metrics will be under.
- METRICS_CONTEXT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsTableAggregateSource
-
The name of the metrics context that metrics will be under.
- METRICS_CONTEXT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsUserAggregateSource
-
The name of the metrics context that metrics will be under.
- METRICS_CONTEXT - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
-
The name of the metrics context that metrics will be under.
- METRICS_CONTEXT - Static variable in interface org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSource
-
The name of the metrics context that metrics will be under.
- METRICS_DESCRIPTION - Static variable in interface org.apache.hadoop.hbase.io.MetricsIOSource
-
Description
- METRICS_DESCRIPTION - Static variable in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
-
Description
- METRICS_DESCRIPTION - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterFileSystemSource
-
Description
- METRICS_DESCRIPTION - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterProcSource
-
Description
- METRICS_DESCRIPTION - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterQuotaSource
- METRICS_DESCRIPTION - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
-
Description
- METRICS_DESCRIPTION - Static variable in interface org.apache.hadoop.hbase.master.MetricsSnapshotSource
-
Description
- METRICS_DESCRIPTION - Static variable in interface org.apache.hadoop.hbase.namequeues.MetricsWALEventTrackerSource
-
Description
- METRICS_DESCRIPTION - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSource
-
Description
- METRICS_DESCRIPTION - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionAggregateSource
-
Description
- METRICS_DESCRIPTION - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerQuotaSource
- METRICS_DESCRIPTION - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
Description
- METRICS_DESCRIPTION - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsTableAggregateSource
-
Description
- METRICS_DESCRIPTION - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsUserAggregateSource
-
Description
- METRICS_DESCRIPTION - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
-
Description
- METRICS_DESCRIPTION - Static variable in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
- METRICS_DESCRIPTION - Static variable in interface org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceFactory
- METRICS_DESCRIPTION - Static variable in interface org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSource
-
Description
- METRICS_JMX_CONTEXT - Static variable in interface org.apache.hadoop.hbase.io.MetricsIOSource
-
The name of the metrics context that metrics will be under in jmx
- METRICS_JMX_CONTEXT - Static variable in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
-
The name of the metrics context that metrics will be under in jmx
- METRICS_JMX_CONTEXT - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterFileSystemSource
-
The name of the metrics context that metrics will be under in jmx
- METRICS_JMX_CONTEXT - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterProcSource
-
The name of the metrics context that metrics will be under in jmx
- METRICS_JMX_CONTEXT - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterQuotaSource
- METRICS_JMX_CONTEXT - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
-
The name of the metrics context that metrics will be under in jmx
- METRICS_JMX_CONTEXT - Static variable in interface org.apache.hadoop.hbase.master.MetricsSnapshotSource
-
The name of the metrics context that metrics will be under in jmx
- METRICS_JMX_CONTEXT - Static variable in interface org.apache.hadoop.hbase.namequeues.MetricsWALEventTrackerSource
-
The name of the metrics context that metrics will be under in jmx
- METRICS_JMX_CONTEXT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSource
-
The name of the metrics context that metrics will be under in jmx
- METRICS_JMX_CONTEXT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionAggregateSource
-
The name of the metrics context that metrics will be under in jmx
- METRICS_JMX_CONTEXT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerQuotaSource
- METRICS_JMX_CONTEXT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
The name of the metrics context that metrics will be under in jmx
- METRICS_JMX_CONTEXT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsTableAggregateSource
-
The name of the metrics context that metrics will be under in jmx
- METRICS_JMX_CONTEXT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsUserAggregateSource
-
The name of the metrics context that metrics will be under in jmx
- METRICS_JMX_CONTEXT - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
-
The name of the metrics context that metrics will be under in jmx
- METRICS_JMX_CONTEXT - Static variable in interface org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSource
-
The name of the metrics context that metrics will be under in jmx.
- METRICS_NAME - Static variable in interface org.apache.hadoop.hbase.io.MetricsIOSource
-
The name of the metrics
- METRICS_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
-
The name of the metrics
- METRICS_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterFileSystemSource
-
The name of the metrics
- METRICS_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterProcSource
-
The name of the metrics
- METRICS_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterQuotaSource
- METRICS_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
-
The name of the metrics
- METRICS_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsSnapshotSource
-
The name of the metrics
- METRICS_NAME - Static variable in interface org.apache.hadoop.hbase.namequeues.MetricsWALEventTrackerSource
-
The name of the metrics
- METRICS_NAME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSource
-
The name of the metrics
- METRICS_NAME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionAggregateSource
-
The name of the metrics
- METRICS_NAME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerQuotaSource
- METRICS_NAME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
The name of the metrics
- METRICS_NAME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsTableAggregateSource
-
The name of the metrics
- METRICS_NAME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsUserAggregateSource
-
The name of the metrics
- METRICS_NAME - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
-
The name of the metrics
- METRICS_NAME - Static variable in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
- METRICS_NAME - Static variable in interface org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceFactory
- METRICS_NAME - Static variable in interface org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSource
-
The name of the metrics
- METRICS_RIT_STUCK_WARNING_THRESHOLD - Static variable in class org.apache.hadoop.hbase.HConstants
-
Region in Transition metrics threshold time
- METRICS_SCOPE_KEY - Static variable in class org.apache.hadoop.hbase.client.MetricsConnection
-
Set to specify a custom scope for the metrics published through
MetricsConnection
. - METRICS_SERVLETS_DEFAULT - Static variable in class org.apache.hadoop.hbase.http.HttpServer
- metricsAdapter - Variable in class org.apache.hadoop.hbase.metrics.BaseSourceImpl
-
The adapter from hbase-metrics module to metrics2.
- org.apache.hadoop.hbase.master.MetricsAssignmentManager - Class in org.apache.hadoop.hbase.master
- MetricsAssignmentManager() - Constructor for class org.apache.hadoop.hbase.master.MetricsAssignmentManager
- org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource - Interface in org.apache.hadoop.hbase.master
- org.apache.hadoop.hbase.master.MetricsAssignmentManagerSourceImpl - Class in org.apache.hadoop.hbase.master
- MetricsAssignmentManagerSourceImpl() - Constructor for class org.apache.hadoop.hbase.master.MetricsAssignmentManagerSourceImpl
- MetricsAssignmentManagerSourceImpl(String, String, String, String) - Constructor for class org.apache.hadoop.hbase.master.MetricsAssignmentManagerSourceImpl
- org.apache.hadoop.hbase.client.MetricsConnection - Class in org.apache.hadoop.hbase.client
-
This class is for maintaining the various connection statistics and publishing them through the metrics interfaces.
- org.apache.hadoop.hbase.client.MetricsConnection.CallStats - Class in org.apache.hadoop.hbase.client
-
A container class for collecting details about the RPC call as it percolates.
- org.apache.hadoop.hbase.client.MetricsConnection.CallTracker - Class in org.apache.hadoop.hbase.client
- org.apache.hadoop.hbase.client.MetricsConnection.RegionStats - Class in org.apache.hadoop.hbase.client
- org.apache.hadoop.hbase.client.MetricsConnection.RunnerStats - Class in org.apache.hadoop.hbase.client
- metricsContext - Variable in class org.apache.hadoop.hbase.metrics.BaseSourceImpl
- metricsContext - Variable in class org.apache.hadoop.hbase.metrics.MetricRegistryInfo
- org.apache.hadoop.hbase.coprocessor.MetricsCoprocessor - Class in org.apache.hadoop.hbase.coprocessor
-
Utility class for tracking metrics for various types of coprocessors.
- MetricsCoprocessor() - Constructor for class org.apache.hadoop.hbase.coprocessor.MetricsCoprocessor
- metricsDescription - Variable in class org.apache.hadoop.hbase.metrics.BaseSourceImpl
- metricsDescription - Variable in class org.apache.hadoop.hbase.metrics.MetricRegistryInfo
- org.apache.hadoop.hbase.metrics.MetricSet - Interface in org.apache.hadoop.hbase.metrics
-
A set of named metrics.
- org.apache.hadoop.metrics2.MetricsExecutor - Interface in org.apache.hadoop.metrics2
-
ScheduledExecutorService for metrics.
- org.apache.hadoop.hbase.ipc.MetricsHBaseServer - Class in org.apache.hadoop.hbase.ipc
- MetricsHBaseServer(String, MetricsHBaseServerWrapper) - Constructor for class org.apache.hadoop.hbase.ipc.MetricsHBaseServer
- org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource - Interface in org.apache.hadoop.hbase.ipc
- org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceFactory - Class in org.apache.hadoop.hbase.ipc
- MetricsHBaseServerSourceFactory() - Constructor for class org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceFactory
- org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceFactoryImpl - Class in org.apache.hadoop.hbase.ipc
- MetricsHBaseServerSourceFactoryImpl() - Constructor for class org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceFactoryImpl
- org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceImpl - Class in org.apache.hadoop.hbase.ipc
- MetricsHBaseServerSourceImpl(String, String, String, String, MetricsHBaseServerWrapper) - Constructor for class org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceImpl
- org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapper - Interface in org.apache.hadoop.hbase.ipc
- org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapperImpl - Class in org.apache.hadoop.hbase.ipc
- org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManager - Class in org.apache.hadoop.hbase.regionserver
-
This class is for maintaining the various regionserver's heap memory manager statistics and publishing them through the metrics interfaces.
- MetricsHeapMemoryManager() - Constructor for class org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManager
- MetricsHeapMemoryManager(MetricsHeapMemoryManagerSource) - Constructor for class org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManager
- org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSource - Interface in org.apache.hadoop.hbase.regionserver
-
This interface will be implemented by a MetricsSource that will export metrics from HeapMemoryManager in RegionServer into the hadoop metrics system.
- org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSourceImpl - Class in org.apache.hadoop.hbase.regionserver
-
Hadoop2 implementation of MetricsHeapMemoryManagerSource.
- MetricsHeapMemoryManagerSourceImpl() - Constructor for class org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSourceImpl
- MetricsHeapMemoryManagerSourceImpl(String, String, String, String) - Constructor for class org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSourceImpl
- org.apache.hadoop.hbase.io.MetricsIO - Class in org.apache.hadoop.hbase.io
- org.apache.hadoop.hbase.io.MetricsIOSource - Interface in org.apache.hadoop.hbase.io
- org.apache.hadoop.hbase.io.MetricsIOSourceImpl - Class in org.apache.hadoop.hbase.io
- MetricsIOSourceImpl(String, String, String, String, MetricsIOWrapper) - Constructor for class org.apache.hadoop.hbase.io.MetricsIOSourceImpl
- MetricsIOSourceImpl(MetricsIOWrapper) - Constructor for class org.apache.hadoop.hbase.io.MetricsIOSourceImpl
- org.apache.hadoop.hbase.io.MetricsIOWrapper - Interface in org.apache.hadoop.hbase.io
- org.apache.hadoop.hbase.io.MetricsIOWrapperImpl - Class in org.apache.hadoop.hbase.io
- MetricsIOWrapperImpl() - Constructor for class org.apache.hadoop.hbase.io.MetricsIOWrapperImpl
- metricsJmxContext - Variable in class org.apache.hadoop.hbase.metrics.BaseSourceImpl
- metricsJmxContext - Variable in class org.apache.hadoop.hbase.metrics.MetricRegistryInfo
- org.apache.hadoop.hbase.master.MetricsMaster - Class in org.apache.hadoop.hbase.master
-
This class is for maintaining the various master statistics and publishing them through the metrics interfaces.
- MetricsMaster(MetricsMasterWrapper) - Constructor for class org.apache.hadoop.hbase.master.MetricsMaster
- org.apache.hadoop.hbase.master.MetricsMasterFileSystem - Class in org.apache.hadoop.hbase.master
- MetricsMasterFileSystem() - Constructor for class org.apache.hadoop.hbase.master.MetricsMasterFileSystem
- org.apache.hadoop.hbase.master.MetricsMasterFileSystemSource - Interface in org.apache.hadoop.hbase.master
- org.apache.hadoop.hbase.master.MetricsMasterFilesystemSourceImpl - Class in org.apache.hadoop.hbase.master
- MetricsMasterFilesystemSourceImpl() - Constructor for class org.apache.hadoop.hbase.master.MetricsMasterFilesystemSourceImpl
- MetricsMasterFilesystemSourceImpl(String, String, String, String) - Constructor for class org.apache.hadoop.hbase.master.MetricsMasterFilesystemSourceImpl
- org.apache.hadoop.hbase.master.MetricsMasterProcSource - Interface in org.apache.hadoop.hbase.master
-
Interface that classes that expose metrics about the master will implement.
- org.apache.hadoop.hbase.master.MetricsMasterProcSourceFactory - Interface in org.apache.hadoop.hbase.master
-
Interface of a factory to create MetricsMasterSource when given a MetricsMasterWrapper
- org.apache.hadoop.hbase.master.MetricsMasterProcSourceFactoryImpl - Class in org.apache.hadoop.hbase.master
-
Factory to create MetricsMasterProcSource when given a MetricsMasterWrapper
- MetricsMasterProcSourceFactoryImpl() - Constructor for class org.apache.hadoop.hbase.master.MetricsMasterProcSourceFactoryImpl
- org.apache.hadoop.hbase.master.MetricsMasterProcSourceImpl - Class in org.apache.hadoop.hbase.master
-
Hadoop2 implementation of MetricsMasterSource.
- MetricsMasterProcSourceImpl(String, String, String, String, MetricsMasterWrapper) - Constructor for class org.apache.hadoop.hbase.master.MetricsMasterProcSourceImpl
- MetricsMasterProcSourceImpl(MetricsMasterWrapper) - Constructor for class org.apache.hadoop.hbase.master.MetricsMasterProcSourceImpl
- org.apache.hadoop.hbase.master.MetricsMasterQuotaSource - Interface in org.apache.hadoop.hbase.master
-
A collection of exposed metrics for space quotas from the HBase Master.
- org.apache.hadoop.hbase.master.MetricsMasterQuotaSourceFactory - Interface in org.apache.hadoop.hbase.master
-
Interface of a factory to create MetricsMasterQuotaSource when given a MetricsMasterWrapper.
- org.apache.hadoop.hbase.master.MetricsMasterQuotaSourceFactoryImpl - Class in org.apache.hadoop.hbase.master
-
Factory to create MetricsMasterQuotaSource instances when given a MetricsMasterWrapper.
- MetricsMasterQuotaSourceFactoryImpl() - Constructor for class org.apache.hadoop.hbase.master.MetricsMasterQuotaSourceFactoryImpl
- org.apache.hadoop.hbase.master.MetricsMasterQuotaSourceImpl - Class in org.apache.hadoop.hbase.master
-
Implementation of
MetricsMasterQuotaSource
which writes the values passed in via the interface to the metrics backend. - MetricsMasterQuotaSourceImpl(String, String, String, String, MetricsMasterWrapper) - Constructor for class org.apache.hadoop.hbase.master.MetricsMasterQuotaSourceImpl
- MetricsMasterQuotaSourceImpl(MetricsMasterWrapper) - Constructor for class org.apache.hadoop.hbase.master.MetricsMasterQuotaSourceImpl
- org.apache.hadoop.hbase.master.MetricsMasterSource - Interface in org.apache.hadoop.hbase.master
-
Interface that classes that expose metrics about the master will implement.
- org.apache.hadoop.hbase.master.MetricsMasterSourceFactory - Interface in org.apache.hadoop.hbase.master
-
Interface of a factory to create MetricsMasterSource when given a MetricsMasterWrapper
- org.apache.hadoop.hbase.master.MetricsMasterSourceFactoryImpl - Class in org.apache.hadoop.hbase.master
-
Factory to create MetricsMasterSource when given a MetricsMasterWrapper
- MetricsMasterSourceFactoryImpl() - Constructor for class org.apache.hadoop.hbase.master.MetricsMasterSourceFactoryImpl
- org.apache.hadoop.hbase.master.MetricsMasterSourceImpl - Class in org.apache.hadoop.hbase.master
-
Hadoop2 implementation of MetricsMasterSource.
- MetricsMasterSourceImpl(String, String, String, String, MetricsMasterWrapper) - Constructor for class org.apache.hadoop.hbase.master.MetricsMasterSourceImpl
- MetricsMasterSourceImpl(MetricsMasterWrapper) - Constructor for class org.apache.hadoop.hbase.master.MetricsMasterSourceImpl
- org.apache.hadoop.hbase.master.MetricsMasterWrapper - Interface in org.apache.hadoop.hbase.master
-
This is the interface that will expose information to hadoop1/hadoop2 implementations of the MetricsMasterSource.
- org.apache.hadoop.hbase.master.MetricsMasterWrapperImpl - Class in org.apache.hadoop.hbase.master
-
Impl for exposing HMaster Information through JMX
- MetricsMasterWrapperImpl(HMaster) - Constructor for class org.apache.hadoop.hbase.master.MetricsMasterWrapperImpl
- metricsName - Variable in class org.apache.hadoop.hbase.metrics.BaseSourceImpl
- metricsName - Variable in class org.apache.hadoop.hbase.metrics.MetricRegistryInfo
- org.apache.hadoop.hbase.regionserver.MetricsRegion - Class in org.apache.hadoop.hbase.regionserver
-
This is the glue between the HRegion and whatever hadoop shim layer is loaded (hbase-hadoop1-compat or hbase-hadoop2-compat).
- MetricsRegion(MetricsRegionWrapper, Configuration) - Constructor for class org.apache.hadoop.hbase.regionserver.MetricsRegion
- org.apache.hadoop.hbase.regionserver.MetricsRegionAggregateSource - Interface in org.apache.hadoop.hbase.regionserver
-
This interface will be implemented by a MetricsSource that will export metrics from multiple regions into the hadoop metrics system.
- org.apache.hadoop.hbase.regionserver.MetricsRegionAggregateSourceImpl - Class in org.apache.hadoop.hbase.regionserver
- MetricsRegionAggregateSourceImpl() - Constructor for class org.apache.hadoop.hbase.regionserver.MetricsRegionAggregateSourceImpl
- MetricsRegionAggregateSourceImpl(String, String, String, String) - Constructor for class org.apache.hadoop.hbase.regionserver.MetricsRegionAggregateSourceImpl
- org.apache.hadoop.hbase.regionserver.MetricsRegionServer - Class in org.apache.hadoop.hbase.regionserver
-
Maintains regionserver statistics and publishes them through the metrics interfaces.
- MetricsRegionServer(MetricsRegionServerWrapper, Configuration, MetricsTable) - Constructor for class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
- org.apache.hadoop.hbase.regionserver.MetricsRegionServerQuotaSource - Interface in org.apache.hadoop.hbase.regionserver
-
A collection of exposed metrics for space quotas from an HBase RegionServer.
- org.apache.hadoop.hbase.regionserver.MetricsRegionServerQuotaSourceImpl - Class in org.apache.hadoop.hbase.regionserver
-
Implementation of
MetricsRegionServerQuotaSource
. - MetricsRegionServerQuotaSourceImpl() - Constructor for class org.apache.hadoop.hbase.regionserver.MetricsRegionServerQuotaSourceImpl
- MetricsRegionServerQuotaSourceImpl(String, String, String, String) - Constructor for class org.apache.hadoop.hbase.regionserver.MetricsRegionServerQuotaSourceImpl
- org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource - Interface in org.apache.hadoop.hbase.regionserver
-
Interface for classes that expose metrics about the regionserver.
- org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceFactory - Interface in org.apache.hadoop.hbase.regionserver
-
Interface of a factory to create Metrics Sources used inside of regionservers.
- org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceFactoryImpl - Class in org.apache.hadoop.hbase.regionserver
-
Factory to create MetricsRegionServerSource when given a MetricsRegionServerWrapper
- MetricsRegionServerSourceFactoryImpl() - Constructor for class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceFactoryImpl
- org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceFactoryImpl.FactoryStorage - Enum Class in org.apache.hadoop.hbase.regionserver
- org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl - Class in org.apache.hadoop.hbase.regionserver
-
Hadoop2 implementation of MetricsRegionServerSource.
- MetricsRegionServerSourceImpl(String, String, String, String, MetricsRegionServerWrapper) - Constructor for class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
- MetricsRegionServerSourceImpl(MetricsRegionServerWrapper) - Constructor for class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
- org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper - Interface in org.apache.hadoop.hbase.regionserver
-
This is the interface that will expose RegionServer information to hadoop1/hadoop2 implementations of the MetricsRegionServerSource.
- org.apache.hadoop.hbase.regionserver.MetricsRegionSource - Interface in org.apache.hadoop.hbase.regionserver
-
This interface will be implemented to allow single regions to push metrics into MetricsRegionAggregateSource that will in turn push data to the Hadoop metrics system.
- org.apache.hadoop.hbase.regionserver.MetricsRegionSourceImpl - Class in org.apache.hadoop.hbase.regionserver
- MetricsRegionSourceImpl(MetricsRegionWrapper, MetricsRegionAggregateSourceImpl) - Constructor for class org.apache.hadoop.hbase.regionserver.MetricsRegionSourceImpl
- org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper - Interface in org.apache.hadoop.hbase.regionserver
-
Interface of class that will wrap an HRegion and export numbers so they can be used in MetricsRegionSource
- org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl - Class in org.apache.hadoop.hbase.regionserver
- MetricsRegionWrapperImpl(HRegion) - Constructor for class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
- org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl.HRegionMetricsWrapperRunnable - Class in org.apache.hadoop.hbase.regionserver
- metricsRegistry - Variable in class org.apache.hadoop.hbase.metrics.BaseSourceImpl
-
Deprecated.Use hbase-metrics/hbase-metrics-api module interfaces for new metrics. Defining BaseSources for new metric groups (WAL, RPC, etc) is not needed anymore, however, for existing
BaseSource
implementations, please use the field named "registry" which is aMetricRegistry
instance together with theHBaseMetrics2HadoopMetricsAdapter
. - org.apache.hadoop.hbase.rest.MetricsREST - Class in org.apache.hadoop.hbase.rest
- MetricsREST() - Constructor for class org.apache.hadoop.hbase.rest.MetricsREST
- org.apache.hadoop.hbase.rest.MetricsRESTSource - Interface in org.apache.hadoop.hbase.rest
-
Interface of the Metrics Source that will export data to Hadoop's Metrics2 system.
- org.apache.hadoop.hbase.rest.MetricsRESTSourceImpl - Class in org.apache.hadoop.hbase.rest
-
Hadoop Two implementation of a metrics2 source that will export metrics from the Rest server to the hadoop metrics2 subsystem.
- MetricsRESTSourceImpl() - Constructor for class org.apache.hadoop.hbase.rest.MetricsRESTSourceImpl
- MetricsRESTSourceImpl(String, String, String, String) - Constructor for class org.apache.hadoop.hbase.rest.MetricsRESTSourceImpl
- org.apache.hadoop.hbase.master.MetricsSnapshot - Class in org.apache.hadoop.hbase.master
- MetricsSnapshot() - Constructor for class org.apache.hadoop.hbase.master.MetricsSnapshot
- org.apache.hadoop.hbase.master.MetricsSnapshotSource - Interface in org.apache.hadoop.hbase.master
- org.apache.hadoop.hbase.master.MetricsSnapshotSourceImpl - Class in org.apache.hadoop.hbase.master
- MetricsSnapshotSourceImpl() - Constructor for class org.apache.hadoop.hbase.master.MetricsSnapshotSourceImpl
- MetricsSnapshotSourceImpl(String, String, String, String) - Constructor for class org.apache.hadoop.hbase.master.MetricsSnapshotSourceImpl
- org.apache.hadoop.hbase.regionserver.MetricsTable - Class in org.apache.hadoop.hbase.regionserver
- MetricsTable(MetricsTableWrapperAggregate) - Constructor for class org.apache.hadoop.hbase.regionserver.MetricsTable
- org.apache.hadoop.hbase.regionserver.MetricsTableAggregateSource - Interface in org.apache.hadoop.hbase.regionserver
-
This interface will be implemented by a MetricsSource that will export metrics from multiple regions of a table into the hadoop metrics system.
- org.apache.hadoop.hbase.regionserver.MetricsTableAggregateSourceImpl - Class in org.apache.hadoop.hbase.regionserver
- MetricsTableAggregateSourceImpl() - Constructor for class org.apache.hadoop.hbase.regionserver.MetricsTableAggregateSourceImpl
- MetricsTableAggregateSourceImpl(String, String, String, String) - Constructor for class org.apache.hadoop.hbase.regionserver.MetricsTableAggregateSourceImpl
- org.apache.hadoop.hbase.regionserver.metrics.MetricsTableRequests - Class in org.apache.hadoop.hbase.regionserver.metrics
- MetricsTableRequests(TableName, Configuration) - Constructor for class org.apache.hadoop.hbase.regionserver.metrics.MetricsTableRequests
- org.apache.hadoop.hbase.regionserver.MetricsTableSource - Interface in org.apache.hadoop.hbase.regionserver
-
This interface will be implemented to allow region server to push table metrics into MetricsRegionAggregateSource that will in turn push data to the Hadoop metrics system.
- org.apache.hadoop.hbase.regionserver.MetricsTableSourceImpl - Class in org.apache.hadoop.hbase.regionserver
- MetricsTableSourceImpl(String, MetricsTableAggregateSourceImpl, MetricsTableWrapperAggregate) - Constructor for class org.apache.hadoop.hbase.regionserver.MetricsTableSourceImpl
- org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregate - Interface in org.apache.hadoop.hbase.regionserver
-
Interface of class that will wrap a MetricsTableSource and export numbers so they can be used in MetricsTableSource
- org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImpl - Class in org.apache.hadoop.hbase.regionserver
- MetricsTableWrapperAggregateImpl(HRegionServer) - Constructor for class org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImpl
- org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImpl.TableMetricsWrapperRunnable - Class in org.apache.hadoop.hbase.regionserver
- org.apache.hadoop.hbase.thrift.MetricsThriftServerSource - Interface in org.apache.hadoop.hbase.thrift
-
Interface of a class that will export metrics about Thrift to hadoop's metrics2.
- org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceFactory - Interface in org.apache.hadoop.hbase.thrift
-
Factory that will be used to create metrics sources for the two diffent types of thrift servers.
- org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceFactoryImpl - Class in org.apache.hadoop.hbase.thrift
-
Class used to create metrics sources for Thrift and Thrift2 servers.
- MetricsThriftServerSourceFactoryImpl() - Constructor for class org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceFactoryImpl
- org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceImpl - Class in org.apache.hadoop.hbase.thrift
-
Hadoop 2 version of
MetricsThriftServerSource
Implements BaseSource through BaseSourceImpl, following the pattern - MetricsThriftServerSourceImpl(String, String, String, String) - Constructor for class org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceImpl
- org.apache.hadoop.hbase.regionserver.MetricsUserAggregate - Interface in org.apache.hadoop.hbase.regionserver
- org.apache.hadoop.hbase.regionserver.MetricsUserAggregateFactory - Class in org.apache.hadoop.hbase.regionserver
- org.apache.hadoop.hbase.regionserver.MetricsUserAggregateImpl - Class in org.apache.hadoop.hbase.regionserver
- MetricsUserAggregateImpl(Configuration) - Constructor for class org.apache.hadoop.hbase.regionserver.MetricsUserAggregateImpl
- org.apache.hadoop.hbase.regionserver.MetricsUserAggregateSource - Interface in org.apache.hadoop.hbase.regionserver
-
This interface will be implemented by a MetricsSource that will export metrics from multiple users into the hadoop metrics system.
- org.apache.hadoop.hbase.regionserver.MetricsUserAggregateSourceImpl - Class in org.apache.hadoop.hbase.regionserver
- MetricsUserAggregateSourceImpl() - Constructor for class org.apache.hadoop.hbase.regionserver.MetricsUserAggregateSourceImpl
- MetricsUserAggregateSourceImpl(String, String, String, String) - Constructor for class org.apache.hadoop.hbase.regionserver.MetricsUserAggregateSourceImpl
- org.apache.hadoop.hbase.regionserver.MetricsUserSource - Interface in org.apache.hadoop.hbase.regionserver
- org.apache.hadoop.hbase.regionserver.MetricsUserSource.ClientMetrics - Interface in org.apache.hadoop.hbase.regionserver
- org.apache.hadoop.hbase.regionserver.MetricsUserSourceImpl - Class in org.apache.hadoop.hbase.regionserver
- MetricsUserSourceImpl(String, MetricsUserAggregateSourceImpl) - Constructor for class org.apache.hadoop.hbase.regionserver.MetricsUserSourceImpl
- org.apache.hadoop.hbase.regionserver.wal.MetricsWAL - Class in org.apache.hadoop.hbase.regionserver.wal
-
Class used to push numbers about the WAL into the metrics subsystem.
- MetricsWAL() - Constructor for class org.apache.hadoop.hbase.regionserver.wal.MetricsWAL
- org.apache.hadoop.hbase.namequeues.MetricsWALEventTrackerSource - Interface in org.apache.hadoop.hbase.namequeues
- org.apache.hadoop.hbase.namequeues.MetricsWALEventTrackerSourceImpl - Class in org.apache.hadoop.hbase.namequeues
- MetricsWALEventTrackerSourceImpl() - Constructor for class org.apache.hadoop.hbase.namequeues.MetricsWALEventTrackerSourceImpl
- MetricsWALEventTrackerSourceImpl(String, String, String, String) - Constructor for class org.apache.hadoop.hbase.namequeues.MetricsWALEventTrackerSourceImpl
- org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource - Interface in org.apache.hadoop.hbase.regionserver.wal
-
Interface of the source that will export metrics about the region server's WAL.
- org.apache.hadoop.hbase.regionserver.wal.MetricsWALSourceImpl - Class in org.apache.hadoop.hbase.regionserver.wal
-
Class that transitions metrics from MetricsWAL into the metrics subsystem.
- MetricsWALSourceImpl() - Constructor for class org.apache.hadoop.hbase.regionserver.wal.MetricsWALSourceImpl
- MetricsWALSourceImpl(String, String, String, String) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.MetricsWALSourceImpl
- org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSource - Interface in org.apache.hadoop.hbase.zookeeper
-
Interface of the source that will export metrics about the ZooKeeper.
- org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSourceImpl - Class in org.apache.hadoop.hbase.zookeeper
-
Class that transitions metrics from MetricsZooKeeper into the metrics subsystem.
- MetricsZooKeeperSourceImpl() - Constructor for class org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSourceImpl
- MetricsZooKeeperSourceImpl(String, String, String, String) - Constructor for class org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSourceImpl
- MID_KEY_METADATA_SIZE - Static variable in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex
-
The size of a meta-data record used for finding the mid-key in a multi-level index.
- midkey(HFile.CachingBlockReader) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileIndexBlockEncoder.EncodedSeeker
- midkey(HFile.CachingBlockReader) - Method in class org.apache.hadoop.hbase.io.hfile.NoOpIndexBlockEncoder.NoOpEncodedSeeker
- midKey() - Method in class org.apache.hadoop.hbase.io.HalfStoreFileReader
- midKey() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
- midKey() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
- midKey() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileReader
- midKeyEntry - Variable in class org.apache.hadoop.hbase.io.hfile.NoOpIndexBlockEncoder.NoOpEncodedSeeker
- midLeafBlockOffset - Variable in class org.apache.hadoop.hbase.io.hfile.NoOpIndexBlockEncoder.NoOpEncodedSeeker
- midLeafBlockOnDiskSize - Variable in class org.apache.hadoop.hbase.io.hfile.NoOpIndexBlockEncoder.NoOpEncodedSeeker
- migrate(Configuration, BiConsumer<String, String>) - Method in class org.apache.hadoop.hbase.regionserver.storefiletracker.ModifyStoreFileTrackerProcedure
- org.apache.hadoop.hbase.rsgroup.MigrateRSGroupProcedure - Class in org.apache.hadoop.hbase.rsgroup
-
Procedure for migrating rs group information to table descriptor.
- MigrateRSGroupProcedure() - Constructor for class org.apache.hadoop.hbase.rsgroup.MigrateRSGroupProcedure
- MigrateRSGroupProcedure(MasterProcedureEnv, TableName) - Constructor for class org.apache.hadoop.hbase.rsgroup.MigrateRSGroupProcedure
- MIGRATION - Enum constant in enum class org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileTrackerFactory.Trackers
- MIGRATION_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
-
Any artifacts left from migration can be moved here
- MIMETYPE_BINARY - Static variable in interface org.apache.hadoop.hbase.rest.Constants
- MIMETYPE_HTML - Static variable in interface org.apache.hadoop.hbase.rest.Constants
- MIMETYPE_JSON - Static variable in interface org.apache.hadoop.hbase.rest.Constants
- MIMETYPE_PROTOBUF - Static variable in interface org.apache.hadoop.hbase.rest.Constants
- MIMETYPE_PROTOBUF_IETF - Static variable in interface org.apache.hadoop.hbase.rest.Constants
- MIMETYPE_TEXT - Static variable in interface org.apache.hadoop.hbase.rest.Constants
- MIMETYPE_XML - Static variable in interface org.apache.hadoop.hbase.rest.Constants
- MIN_AGE_TO_ARCHIVE_KEY - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
-
Minimum MOB file age to archive, default (3600000 - 1h)
- MIN_ALLOCATE_SIZE_KEY - Static variable in class org.apache.hadoop.hbase.io.ByteBuffAllocator
- MIN_CLIENT_REQUEST_TIMEOUT - Static variable in class org.apache.hadoop.hbase.ipc.RpcServer
-
Minimum allowable timeout (in milliseconds) in rpc request's header.
- MIN_CORE_POOL_SIZE - Static variable in class org.apache.hadoop.hbase.ChoreService
-
The minimum number of threads in the core pool of the underlying ScheduledThreadPoolExecutor
- MIN_FILES_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.StripeStoreConfig
-
The minimum number of files to compact within a stripe; same as for regular compaction.
- MIN_FILES_L0_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.StripeStoreConfig
-
The minimum number of files to compact when compacting L0; same as minFiles for regular compaction.
- MIN_FORMAT_VERSION - Static variable in class org.apache.hadoop.hbase.io.hfile.HFile
-
Minimum supported HFile format version
- MIN_FORMAT_VERSION_WITH_TAGS - Static variable in class org.apache.hadoop.hbase.io.hfile.HFile
-
Minimum HFile format version with support for persisting cell tags
- MIN_INDEX_NUM_ENTRIES_KEY - Static variable in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex
-
Minimum number of entries in a single index block.
- MIN_KEEP_SEQID_PERIOD - Static variable in class org.apache.hadoop.hbase.HConstants
-
At least to keep MVCC values in hfiles for 5 days
- MIN_METRIC_NAME - Static variable in interface org.apache.hadoop.metrics2.MetricHistogram
- MIN_NUM_HFILE_PATH_LEVELS - Static variable in class org.apache.hadoop.hbase.io.hfile.HFile
-
We assume that HFile path ends with ROOT_DIR/TABLE_NAME/REGION_NAME/CF_NAME/HFILE, so it has at least this many levels of nesting.
- MIN_SECS_BETWEEN_REFRESHES - Static variable in class org.apache.hadoop.hbase.client.RpcConnectionRegistry
- MIN_STORE_FILE_AGE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- MIN_STORE_FILE_AGE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- MIN_VERSIONS - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
- MIN_WORKER_THREADS_CONF_KEY - Static variable in class org.apache.hadoop.hbase.thrift.TBoundedThreadPoolServer
-
The "core size" of the thread pool.
- MIN_WORKERS_OPTION - Static variable in class org.apache.hadoop.hbase.thrift.Constants
- MIN_WRITE_BUFFER_PERIODIC_FLUSH_TIMERTICK_MS - Static variable in interface org.apache.hadoop.hbase.client.BufferedMutator
-
Having the timer tick run more often that once every 100ms is needless and will probably cause too many timer events firing having a negative impact on performance.
- minCellIdx - Variable in class org.apache.hadoop.hbase.regionserver.CellFlatMap
- minClientRequestTimeout - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
- minColDataSize - Variable in class org.apache.hadoop.hbase.util.LoadTestTool
- minColsPerKey - Variable in class org.apache.hadoop.hbase.util.LoadTestTool
- minColumn - Variable in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
- minColumnInclusive - Variable in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
- org.apache.hadoop.hbase.regionserver.MiniBatchOperationInProgress<T> - Class in org.apache.hadoop.hbase.regionserver
-
Wraps together the mutations which are applied as a batch to the region and their operation status and WALEdits.
- MiniBatchOperationInProgress(T[], OperationStatus[], WALEdit[], int, int, int) - Constructor for class org.apache.hadoop.hbase.regionserver.MiniBatchOperationInProgress
- minIdleTimeBeforeClose - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
- org.apache.hadoop.hbase.MiniHBaseCluster - Class in org.apache.hadoop.hbase
-
Deprecated.since 3.0.0, will be removed in 4.0.0. Use
TestingHBaseCluster
instead. - MiniHBaseCluster(Configuration, int) - Constructor for class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.Start a MiniHBaseCluster.
- MiniHBaseCluster(Configuration, int, int) - Constructor for class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.Start a MiniHBaseCluster.
- MiniHBaseCluster(Configuration, int, int, int, List<Integer>, Class<? extends HMaster>, Class<? extends MiniHBaseCluster.MiniHBaseClusterRegionServer>) - Constructor for class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.
- MiniHBaseCluster(Configuration, int, int, Class<? extends HMaster>, Class<? extends MiniHBaseCluster.MiniHBaseClusterRegionServer>) - Constructor for class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.Start a MiniHBaseCluster.
- org.apache.hadoop.hbase.MiniHBaseCluster.MiniHBaseClusterRegionServer - Class in org.apache.hadoop.hbase
-
Deprecated.Subclass so can get at protected methods (none at moment).
- MiniHBaseClusterRegionServer(Configuration) - Constructor for class org.apache.hadoop.hbase.MiniHBaseCluster.MiniHBaseClusterRegionServer
-
Deprecated.
- Minimum - Enum constant in enum class org.apache.hadoop.hbase.KeyValue.Type
- org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster - Class in org.apache.hadoop.hbase.zookeeper
-
TODO: Most of the code in this class is ripped from ZooKeeper tests.
- MiniZooKeeperCluster() - Constructor for class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
- MiniZooKeeperCluster(Configuration) - Constructor for class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
- MINOR - Enum constant in enum class org.apache.hadoop.hbase.client.CompactionState
- MINOR_VERSION - Static variable in exception org.apache.hadoop.hbase.exceptions.RequestTooBigException
- MINOR_VERSION_NO_CHECKSUM - Static variable in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
-
In HFile minor version that does not support checksums
- MINOR_VERSION_WITH_CHECKSUM - Static variable in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
-
Minor versions in HFile starting with this number have hbase checksums
- org.apache.hadoop.hbase.regionserver.querymatcher.MinorCompactionScanQueryMatcher - Class in org.apache.hadoop.hbase.regionserver.querymatcher
-
Query matcher for minor compaction.
- MinorCompactionScanQueryMatcher(ScanInfo, DeleteTracker, ColumnTracker, long, long, long) - Constructor for class org.apache.hadoop.hbase.regionserver.querymatcher.MinorCompactionScanQueryMatcher
- minSequenceId - Variable in class org.apache.hadoop.hbase.regionserver.Segment
- MINUS_SIGN - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
ASCII for Minus Sign
- MINUTE_IN_SECONDS - Static variable in class org.apache.hadoop.hbase.HConstants
- miss(boolean, boolean, BlockType) - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
- MISSING_FILES - Enum constant in enum class org.apache.hadoop.hbase.snapshot.ExportSnapshot.Counter
- org.apache.hadoop.hbase.quotas.policies.MissingSnapshotViolationPolicyEnforcement - Class in org.apache.hadoop.hbase.quotas.policies
-
A
SpaceViolationPolicyEnforcement
which can be treated as a singleton. - MIXED_ROW_READS - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
- MIXED_ROW_READS_ON_STORE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
- MOB - Enum constant in enum class org.apache.hadoop.hbase.client.CompactType
- MOB_CACHE_BLOCKS - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
- MOB_CACHE_EVICT_PERIOD - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
- MOB_CACHE_EVICT_REMAIN_RATIO - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
- MOB_CELLS_COUNT - Static variable in class org.apache.hadoop.hbase.regionserver.HStoreFile
-
Key for the number of mob cells in metadata
- MOB_CLEANER_BATCH_SIZE_UPPER_BOUND - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
- MOB_CLEANER_PERIOD - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
- MOB_COMPACT_PARTITION_POLICY - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
- MOB_COMPACTION_BATCH_SIZE - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
-
The max number of the mob files that is allowed in a batch of the mob compaction.
- MOB_COMPACTION_CHORE_PERIOD - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
-
The period that MobCompactionChore runs.
- MOB_COMPACTION_MAX_FILE_SIZE_KEY - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
-
Maximum size of a MOB compaction selection
- MOB_COMPACTION_MERGEABLE_THRESHOLD - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
-
If the size of a mob file is less than this value, it's regarded as a small file and needs to be merged in mob compaction.
- MOB_COMPACTION_THREADS_MAX - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
- MOB_COMPACTION_TYPE_KEY - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
- MOB_COMPACTOR_CLASS_KEY - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
- MOB_COMPACTOR_CLASS_KEY - Static variable in class org.apache.hadoop.hbase.mob.MobStoreEngine
- MOB_DELFILE_MAX_COUNT - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
- MOB_DIR_NAME - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
- MOB_FILE_CACHE_ACCESS_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- MOB_FILE_CACHE_ACCESS_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- MOB_FILE_CACHE_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- MOB_FILE_CACHE_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- MOB_FILE_CACHE_EVICTED_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- MOB_FILE_CACHE_EVICTED_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- MOB_FILE_CACHE_HIT_PERCENT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- MOB_FILE_CACHE_HIT_PERCENT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- MOB_FILE_CACHE_MISS_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- MOB_FILE_CACHE_MISS_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- MOB_FILE_CACHE_SIZE_KEY - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
- MOB_FILE_REFS - Static variable in class org.apache.hadoop.hbase.regionserver.HStoreFile
-
Key for the list of MOB file references
- MOB_FLUSH_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- MOB_FLUSH_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- MOB_FLUSHED_CELLS_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- MOB_FLUSHED_CELLS_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- MOB_FLUSHED_CELLS_SIZE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- MOB_FLUSHED_CELLS_SIZE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- MOB_MAJOR_COMPACTION_REGION_BATCH_SIZE - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
-
The max number of a MOB table regions that is allowed in a batch of the mob compaction.
- MOB_REF_TAG - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
- MOB_REFERENCE_TAG_TYPE - Static variable in class org.apache.hadoop.hbase.TagType
- MOB_REGION_NAME - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
- MOB_REGION_NAME_BYTES - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
- MOB_SCAN_CELLS_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- MOB_SCAN_CELLS_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- MOB_SCAN_CELLS_SIZE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- MOB_SCAN_CELLS_SIZE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- MOB_SCAN_RAW - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
- MOB_SCAN_REF_ONLY - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
- MOB_TABLE_LOCK_SUFFIX - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
- MOB_TABLE_NAME_TAG_TYPE - Static variable in class org.apache.hadoop.hbase.TagType
- MOB_THRESHOLD - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
- MOB_UNSAFE_DISCARD_MISS_KEY - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
-
Use this configuration option with caution, only during upgrade procedure to handle missing MOB cells during compaction.
- org.apache.hadoop.hbase.mob.MobCell - Class in org.apache.hadoop.hbase.mob
-
The MobCell will maintain a
Cell
and aStoreFileScanner
inside. - MobCell(ExtendedCell) - Constructor for class org.apache.hadoop.hbase.mob.MobCell
- MobCell(ExtendedCell, StoreFileScanner) - Constructor for class org.apache.hadoop.hbase.mob.MobCell
- org.apache.hadoop.hbase.client.MobCompactPartitionPolicy - Enum Class in org.apache.hadoop.hbase.client
-
Enum describing the mob compact partition policy types.
- org.apache.hadoop.hbase.mob.MobConstants - Class in org.apache.hadoop.hbase.mob
-
The constants used in mob.
- org.apache.hadoop.hbase.mob.MobFile - Class in org.apache.hadoop.hbase.mob
-
The mob file.
- MobFile() - Constructor for class org.apache.hadoop.hbase.mob.MobFile
- MobFile(HStoreFile) - Constructor for class org.apache.hadoop.hbase.mob.MobFile
- org.apache.hadoop.hbase.mob.MobFileCache - Class in org.apache.hadoop.hbase.mob
-
The cache for mob files.
- MobFileCache(Configuration) - Constructor for class org.apache.hadoop.hbase.mob.MobFileCache
- org.apache.hadoop.hbase.mob.MobFileCleanerChore - Class in org.apache.hadoop.hbase.mob
-
The class MobFileCleanerChore for running cleaner regularly to remove the expired and obsolete (files which have no active references to) mob files.
- MobFileCleanerChore(HMaster) - Constructor for class org.apache.hadoop.hbase.mob.MobFileCleanerChore
- org.apache.hadoop.hbase.mob.MobFileCleanupUtil - Class in org.apache.hadoop.hbase.mob
- org.apache.hadoop.hbase.mob.MobFileCompactionChore - Class in org.apache.hadoop.hbase.mob
-
Periodic MOB compaction chore.
- MobFileCompactionChore(Configuration, int) - Constructor for class org.apache.hadoop.hbase.mob.MobFileCompactionChore
- MobFileCompactionChore(HMaster) - Constructor for class org.apache.hadoop.hbase.mob.MobFileCompactionChore
- org.apache.hadoop.hbase.mob.MobFileName - Class in org.apache.hadoop.hbase.mob
-
The mob file name.
- MobRefMapper() - Constructor for class org.apache.hadoop.hbase.mob.mapreduce.MobRefReporter.MobRefMapper
- MobRefReducer() - Constructor for class org.apache.hadoop.hbase.mob.mapreduce.MobRefReporter.MobRefReducer
- org.apache.hadoop.hbase.mob.mapreduce.MobRefReporter - Class in org.apache.hadoop.hbase.mob.mapreduce
-
Scans a given table + CF for all mob reference cells to get the list of backing mob files.
- MobRefReporter() - Constructor for class org.apache.hadoop.hbase.mob.mapreduce.MobRefReporter
- org.apache.hadoop.hbase.mob.mapreduce.MobRefReporter.MobRefMapper - Class in org.apache.hadoop.hbase.mob.mapreduce
- org.apache.hadoop.hbase.mob.mapreduce.MobRefReporter.MobRefReducer - Class in org.apache.hadoop.hbase.mob.mapreduce
- mobSizeThreshold - Variable in class org.apache.hadoop.hbase.mob.DefaultMobStoreCompactor
- mobStore - Variable in class org.apache.hadoop.hbase.mob.DefaultMobStoreCompactor
- org.apache.hadoop.hbase.mob.MobStoreEngine - Class in org.apache.hadoop.hbase.mob
-
MobStoreEngine creates the mob specific compactor, and store flusher.
- MobStoreEngine() - Constructor for class org.apache.hadoop.hbase.mob.MobStoreEngine
- org.apache.hadoop.hbase.regionserver.MobStoreScanner - Class in org.apache.hadoop.hbase.regionserver
-
Scanner scans both the memstore and the MOB Store.
- MobStoreScanner(HStore, ScanInfo, Scan, NavigableSet<byte[]>, long) - Constructor for class org.apache.hadoop.hbase.regionserver.MobStoreScanner
- org.apache.hadoop.hbase.mob.MobUtils - Class in org.apache.hadoop.hbase.mob
-
The mob utilities
- org.apache.hadoop.hbase.io.crypto.MockAesKeyProvider - Class in org.apache.hadoop.hbase.io.crypto
-
Return a fixed secret key for AES for testing.
- MockAesKeyProvider() - Constructor for class org.apache.hadoop.hbase.io.crypto.MockAesKeyProvider
- org.apache.hadoop.hbase.MockRegionServerServices - Class in org.apache.hadoop.hbase
-
Basic mock region server services.
- MockRegionServerServices() - Constructor for class org.apache.hadoop.hbase.MockRegionServerServices
- MockRegionServerServices(Configuration) - Constructor for class org.apache.hadoop.hbase.MockRegionServerServices
- MockRegionServerServices(ZKWatcher) - Constructor for class org.apache.hadoop.hbase.MockRegionServerServices
- MockRegionServerServices(ZKWatcher, ServerName) - Constructor for class org.apache.hadoop.hbase.MockRegionServerServices
- org.apache.hadoop.hbase.hbtop.mode.Mode - Enum Class in org.apache.hadoop.hbase.hbtop.mode
-
Represents a display mode in the top screen.
- org.apache.hadoop.hbase.hbtop.screen.mode.ModeScreenPresenter - Class in org.apache.hadoop.hbase.hbtop.screen.mode
-
The presentation logic for the mode screen.
- ModeScreenPresenter(ModeScreenView, Mode, Consumer<Mode>, ScreenView) - Constructor for class org.apache.hadoop.hbase.hbtop.screen.mode.ModeScreenPresenter
- org.apache.hadoop.hbase.hbtop.screen.mode.ModeScreenView - Class in org.apache.hadoop.hbase.hbtop.screen.mode
-
The screen where we can choose the
Mode
in the top screen. - ModeScreenView(Screen, Terminal, Mode, Consumer<Mode>, ScreenView) - Constructor for class org.apache.hadoop.hbase.hbtop.screen.mode.ModeScreenView
- org.apache.hadoop.hbase.hbtop.mode.ModeStrategyUtils - Class in org.apache.hadoop.hbase.hbtop.mode
- modify(MasterProcedureEnv, TableDescriptor) - Method in class org.apache.hadoop.hbase.regionserver.storefiletracker.InitializeStoreFileTrackerProcedure
- modify(MasterProcedureEnv, TableDescriptor) - Method in class org.apache.hadoop.hbase.rsgroup.MigrateRSGroupProcedure
- modifyColumn(TableName, ColumnFamilyDescriptor, long, long) - Method in class org.apache.hadoop.hbase.master.HMaster
- modifyColumn(TableName, ColumnFamilyDescriptor, long, long) - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Modify the column descriptor of an existing column in an existing table
- modifyColumn(RpcController, MasterProtos.ModifyColumnRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- modifyColumnFamily(ColumnFamilyDescriptor) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
- modifyColumnFamily(TableName, ColumnFamilyDescriptor) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Modify an existing column family on a table.
- modifyColumnFamily(TableName, ColumnFamilyDescriptor) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Modify an existing column family on a table.
- modifyColumnFamilyAsync(TableName, ColumnFamilyDescriptor) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Modify an existing column family on a table.
- modifyColumnFamilyStoreFileTracker(TableName, byte[], String) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Change the store file tracker of the given table's given family.
- modifyColumnFamilyStoreFileTracker(TableName, byte[], String) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Change the store file tracker of the given table's given family.
- modifyColumnFamilyStoreFileTrackerAsync(TableName, byte[], String) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Change the store file tracker of the given table's given family.
- org.apache.hadoop.hbase.regionserver.storefiletracker.ModifyColumnFamilyStoreFileTrackerProcedure - Class in org.apache.hadoop.hbase.regionserver.storefiletracker
- ModifyColumnFamilyStoreFileTrackerProcedure() - Constructor for class org.apache.hadoop.hbase.regionserver.storefiletracker.ModifyColumnFamilyStoreFileTrackerProcedure
- ModifyColumnFamilyStoreFileTrackerProcedure(MasterProcedureEnv, TableName, byte[], String) - Constructor for class org.apache.hadoop.hbase.regionserver.storefiletracker.ModifyColumnFamilyStoreFileTrackerProcedure
- modifyColumnStoreFileTracker(TableName, byte[], String, long, long) - Method in class org.apache.hadoop.hbase.master.HMaster
- modifyColumnStoreFileTracker(TableName, byte[], String, long, long) - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Modify the store file tracker of an existing column in an existing table
- modifyColumnStoreFileTracker(RpcController, MasterProtos.ModifyColumnStoreFileTrackerRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- modifyNamespace(NamespaceDescriptor) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Modify an existing namespace.
- modifyNamespace(NamespaceDescriptor) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Modify an existing namespace.
- modifyNamespace(NamespaceDescriptor, NonceKey, ProcedurePrepareLatch) - Method in interface org.apache.hadoop.hbase.master.ClusterSchema
-
Modify an existing Namespace.
- modifyNamespace(RpcController, MasterProtos.ModifyNamespaceRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- modifyNamespaceAsync(NamespaceDescriptor) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Modify an existing namespace.
- org.apache.hadoop.hbase.util.ModifyRegionUtils - Class in org.apache.hadoop.hbase.util
-
Utility methods for interacting with the regions.
- org.apache.hadoop.hbase.util.ModifyRegionUtils.RegionEditTask - Interface in org.apache.hadoop.hbase.util
- org.apache.hadoop.hbase.util.ModifyRegionUtils.RegionFillTask - Interface in org.apache.hadoop.hbase.util
- org.apache.hadoop.hbase.regionserver.storefiletracker.ModifyStoreFileTrackerProcedure - Class in org.apache.hadoop.hbase.regionserver.storefiletracker
-
This procedure is used to change the store file tracker implementation.
- ModifyStoreFileTrackerProcedure() - Constructor for class org.apache.hadoop.hbase.regionserver.storefiletracker.ModifyStoreFileTrackerProcedure
- ModifyStoreFileTrackerProcedure(MasterProcedureEnv, TableName, String) - Constructor for class org.apache.hadoop.hbase.regionserver.storefiletracker.ModifyStoreFileTrackerProcedure
- modifyTable(TableDescriptor) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Modify an existing table, more IRB friendly version.
- modifyTable(TableDescriptor) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Modify an existing table, more IRB friendly version.
- modifyTable(TableDescriptor, boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Modify an existing table, more IRB friendly version.
- modifyTable(TableName, TableDescriptor, long, long) - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Modify the descriptor of an existing table
- modifyTable(TableName, TableDescriptor, long, long, boolean) - Method in class org.apache.hadoop.hbase.master.HMaster
- modifyTable(TableName, TableDescriptor, long, long, boolean) - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Modify the descriptor of an existing table
- modifyTable(RpcController, MasterProtos.ModifyTableRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- modifyTableAsync(TableDescriptor) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Modify an existing table, more IRB (ruby) friendly version.
- modifyTableAsync(TableDescriptor, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
-
The same as
Admin.modifyTableAsync(TableDescriptor td)
, except for the reopenRegions parameter, which controls whether the process of modifying the table should reopen all regions. - modifyTableStoreFileTracker(TableName, String) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Change the store file tracker of the given table.
- modifyTableStoreFileTracker(TableName, String) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Change the store file tracker of the given table.
- modifyTableStoreFileTracker(TableName, String, long, long) - Method in class org.apache.hadoop.hbase.master.HMaster
- modifyTableStoreFileTracker(TableName, String, long, long) - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Modify the store file tracker of an existing table
- modifyTableStoreFileTracker(RpcController, MasterProtos.ModifyTableStoreFileTrackerRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- modifyTableStoreFileTrackerAsync(TableName, String) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Change the store file tracker of the given table.
- org.apache.hadoop.hbase.regionserver.storefiletracker.ModifyTableStoreFileTrackerProcedure - Class in org.apache.hadoop.hbase.regionserver.storefiletracker
- ModifyTableStoreFileTrackerProcedure() - Constructor for class org.apache.hadoop.hbase.regionserver.storefiletracker.ModifyTableStoreFileTrackerProcedure
- ModifyTableStoreFileTrackerProcedure(MasterProcedureEnv, TableName, String) - Constructor for class org.apache.hadoop.hbase.regionserver.storefiletracker.ModifyTableStoreFileTrackerProcedure
- modifyTableSync(Admin, TableDescriptor) - Static method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.since 3.0.0 and will be removed in 4.0.0. Just use
Admin.modifyTable(TableDescriptor)
directly as it is synchronous now. - MONITORED_RPC - Static variable in class org.apache.hadoop.hbase.ipc.RpcServer
-
Keeps MonitoredRPCHandler per handler thread.
- MONTHLY - Enum constant in enum class org.apache.hadoop.hbase.client.MobCompactPartitionPolicy
-
Compact mob files within one calendar month into one file
- MORE_VALUES - Enum constant in enum class org.apache.hadoop.hbase.regionserver.ScannerContext.NextState
- moreRowsMayExistAfter(ExtendedCell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.CompactionScanQueryMatcher
- moreRowsMayExistAfter(ExtendedCell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher
- moreRowsMayExistAfter(ExtendedCell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.UserScanQueryMatcher
- moreRowsMayExistsAfter(int) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.UserScanQueryMatcher
- mostRecent - Variable in class org.apache.hadoop.hbase.util.WindowMovingAverage
- move(byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Move the region
encodedRegionName
to a random server. - move(byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Move the region
r
to a random server. - move(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Deprecated.since 2.2.0 and will be removed in 4.0.0. Use
Admin.move(byte[], ServerName)
instead. And if you want to move the region to a random server, please useAdmin.move(byte[])
. - move(byte[], byte[]) - Method in class org.apache.hadoop.hbase.master.HMaster
- move(byte[], ServerName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Move the region
encodedRegionName
todestServerName
. - move(byte[], ServerName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Move the region
r
todest
. - MOVE_METRIC_PREFIX - Static variable in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
- MOVE_RETRIES_MAX_KEY - Static variable in class org.apache.hadoop.hbase.util.RegionMover
- MOVE_WAIT_MAX_KEY - Static variable in class org.apache.hadoop.hbase.util.RegionMover
- moveAsideBadEditsFile(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.wal.WALSplitUtil
-
Move aside a bad edits file.
- moveBack(int) - Method in class org.apache.hadoop.hbase.nio.ByteBuff
-
Jumps back the current position of this ByteBuff by specified length.
- moveBack(int) - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
Jumps back the current position of this MBB by specified length.
- moveBack(int) - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
- moveBufferToStream(OutputStream, ByteBuffer, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Copy the data to the output stream and update position in buffer.
- moveCursor(int, int) - Static method in class org.apache.hadoop.hbase.hbtop.terminal.impl.EscapeSequences
- movedRegionCacheExpiredTime() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
- movedRegionException() - Method in interface org.apache.hadoop.hbase.metrics.ExceptionTrackingSource
- movedRegionException() - Method in class org.apache.hadoop.hbase.metrics.ExceptionTrackingSourceImpl
- moveForwardMostRecentPosition() - Method in class org.apache.hadoop.hbase.util.WindowMovingAverage
-
Move forward the most recent index.
- moveFromOnlineToDeadServers(ServerName) - Method in class org.apache.hadoop.hbase.master.ServerManager
-
Called when server has expired.
- moveRegion(RpcController, MasterProtos.MoveRegionRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- moveRegionAndWait(RegionInfo, ServerName) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Move region to destination server and wait till region is completely moved and online
- moveServers(Set<Address>, String) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminClient
-
Deprecated.Move given set of servers to the specified target RegionServer group.
- moveServers(Set<Address>, String) - Method in interface org.apache.hadoop.hbase.rsgroup.RSGroupInfoManager
-
Move servers to a new group.
- moveServers(RpcController, RSGroupAdminProtos.MoveServersRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- moveServersAndTables(Set<Address>, Set<TableName>, String) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminClient
-
Deprecated.Move given set of servers and tables to the specified target RegionServer group.
- moveServersToRSGroup(Set<Address>, String) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Move given set of servers to the specified target RegionServer group
- moveServersToRSGroup(Set<Address>, String) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Move given set of servers to the specified target RegionServer group
- moveTables(Set<TableName>, String) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminClient
-
Deprecated.Move given set of tables to the specified target RegionServer group.
- moveWAL(FileSystem, Path, Path) - Static method in class org.apache.hadoop.hbase.wal.WALSplitUtil
-
Move WAL.
- org.apache.hadoop.hbase.util.MovingAverage<T> - Class in org.apache.hadoop.hbase.util
-
The purpose of introduction of
MovingAverage
mainly is to measure execution time of a specific method, which can help us to know its performance fluctuation in response to different machine states or situations, better case, then to act accordingly. - MovingAverage(String) - Constructor for class org.apache.hadoop.hbase.util.MovingAverage
- msgInterval - Variable in class org.apache.hadoop.hbase.HBaseServerBase
- MSLAB_CLASS_NAME - Static variable in interface org.apache.hadoop.hbase.regionserver.MemStoreLAB
- multi(Iterable<Op>) - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
Run multiple operations in a transactional manner.
- multi(RpcController, ClientProtos.MultiRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
Execute multiple actions on a table: get, mutate, and/or execCoprocessor
- MULTI - Enum constant in enum class org.apache.hadoop.hbase.io.hfile.BlockPriority
-
Accessed multiple times
- MULTI_BYTE_BUFFER_HEAP_SIZE - Static variable in class org.apache.hadoop.hbase.io.hfile.HFileBlock
- MULTI_DEPLOYED - Enum constant in enum class org.apache.hadoop.hbase.util.HbckErrorReporter.ERROR_CODE
-
Deprecated.
- MULTI_META_REGION - Enum constant in enum class org.apache.hadoop.hbase.util.HbckErrorReporter.ERROR_CODE
-
Deprecated.
- MULTI_TABLES_SUPPORT - Static variable in class org.apache.hadoop.hbase.mapreduce.WALPlayer
- org.apache.hadoop.hbase.MultiActionResultTooLarge - Exception in org.apache.hadoop.hbase
-
Exception thrown when the result needs to be chunked on the server side.
- MultiActionResultTooLarge(String) - Constructor for exception org.apache.hadoop.hbase.MultiActionResultTooLarge
- multiActionTooLargeException() - Method in interface org.apache.hadoop.hbase.metrics.ExceptionTrackingSource
- multiActionTooLargeException() - Method in class org.apache.hadoop.hbase.metrics.ExceptionTrackingSourceImpl
- org.apache.hadoop.hbase.nio.MultiByteBuff - Class in org.apache.hadoop.hbase.nio
-
Provides a unified view of all the underlying ByteBuffers and will look as if a bigger sequential buffer.
- MultiByteBuff(ByteBuffer...) - Constructor for class org.apache.hadoop.hbase.nio.MultiByteBuff
- MultiByteBuff(ByteBuffAllocator.Recycler, ByteBuffer...) - Constructor for class org.apache.hadoop.hbase.nio.MultiByteBuff
- MulticastPublisher() - Constructor for class org.apache.hadoop.hbase.master.ClusterStatusPublisher.MulticastPublisher
- multiOrSequential(ZKWatcher, List<ZKUtil.ZKUtilOp>, boolean) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Use ZooKeeper's multi-update functionality.
- multiple(byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Create a byte array which is multiple given bytes
- org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter - Class in org.apache.hadoop.hbase.filter
-
This filter is used for selecting only those keys with columns that matches a particular prefix.
- MultipleColumnPrefixFilter(byte[][]) - Constructor for class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
- multiply(S, S) - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
-
Returns multiplication
- org.apache.hadoop.hbase.client.MultiResponse - Class in org.apache.hadoop.hbase.client
-
A container for Result objects, grouped by regionName.
- MultiResponse() - Constructor for class org.apache.hadoop.hbase.client.MultiResponse
- org.apache.hadoop.hbase.coprocessor.MultiRowMutationEndpoint - Class in org.apache.hadoop.hbase.coprocessor
-
This class implements atomic multi row transactions using
HRegion.mutateRowsWithLocks(Collection, Collection, long, long)
and Coprocessor endpoints. - MultiRowMutationEndpoint() - Constructor for class org.apache.hadoop.hbase.coprocessor.MultiRowMutationEndpoint
- org.apache.hadoop.hbase.filter.MultiRowRangeFilter - Class in org.apache.hadoop.hbase.filter
-
Filter to support scan multiple row key ranges.
- MultiRowRangeFilter(byte[][]) - Constructor for class org.apache.hadoop.hbase.filter.MultiRowRangeFilter
-
Constructor for creating a
MultiRowRangeFilter
from multiple rowkey prefixes. - MultiRowRangeFilter(List<MultiRowRangeFilter.RowRange>) - Constructor for class org.apache.hadoop.hbase.filter.MultiRowRangeFilter
- org.apache.hadoop.hbase.filter.MultiRowRangeFilter.RowRange - Class in org.apache.hadoop.hbase.filter
- org.apache.hadoop.hbase.rest.MultiRowResource - Class in org.apache.hadoop.hbase.rest
- MultiRowResource(TableResource, String, String) - Constructor for class org.apache.hadoop.hbase.rest.MultiRowResource
-
Constructor
- org.apache.hadoop.hbase.rest.MultiRowResultReader - Class in org.apache.hadoop.hbase.rest
- MultiRowResultReader(String, Collection<RowSpec>, Filter, boolean) - Constructor for class org.apache.hadoop.hbase.rest.MultiRowResultReader
- org.apache.hadoop.hbase.mapreduce.MultiTableHFileOutputFormat - Class in org.apache.hadoop.hbase.mapreduce
-
Create 3 level tree directory, first level is using table name as parent directory and then use family name as child directory, and all related HFiles for one family are under child directory -tableName1 -columnFamilyName1 -columnFamilyName2 -HFiles -tableName2 -columnFamilyName1 -HFiles -columnFamilyName2
- MultiTableHFileOutputFormat() - Constructor for class org.apache.hadoop.hbase.mapreduce.MultiTableHFileOutputFormat
- org.apache.hadoop.hbase.mapreduce.MultiTableInputFormat - Class in org.apache.hadoop.hbase.mapreduce
-
Convert HBase tabular data from multiple scanners into a format that is consumable by Map/Reduce.
- MultiTableInputFormat() - Constructor for class org.apache.hadoop.hbase.mapreduce.MultiTableInputFormat
- org.apache.hadoop.hbase.mapreduce.MultiTableInputFormatBase - Class in org.apache.hadoop.hbase.mapreduce
-
A base for
MultiTableInputFormat
s. - MultiTableInputFormatBase() - Constructor for class org.apache.hadoop.hbase.mapreduce.MultiTableInputFormatBase
- org.apache.hadoop.hbase.mapreduce.MultiTableOutputFormat - Class in org.apache.hadoop.hbase.mapreduce
-
Hadoop output format that writes to one or more HBase tables.
- MultiTableOutputFormat() - Constructor for class org.apache.hadoop.hbase.mapreduce.MultiTableOutputFormat
- org.apache.hadoop.hbase.mapreduce.MultiTableOutputFormat.MultiTableRecordWriter - Class in org.apache.hadoop.hbase.mapreduce
-
Record writer for outputting to multiple HTables.
- MultiTableRecordWriter(Configuration, boolean) - Constructor for class org.apache.hadoop.hbase.mapreduce.MultiTableOutputFormat.MultiTableRecordWriter
-
HBaseConfiguration to used whether to use write ahead logging.
- org.apache.hadoop.hbase.mapred.MultiTableSnapshotInputFormat - Class in org.apache.hadoop.hbase.mapred
-
MultiTableSnapshotInputFormat generalizes
TableSnapshotInputFormat
allowing a MapReduce job to run over one or more table snapshots, with one or more scans configured for each. - org.apache.hadoop.hbase.mapreduce.MultiTableSnapshotInputFormat - Class in org.apache.hadoop.hbase.mapreduce
-
MultiTableSnapshotInputFormat generalizes
TableSnapshotInputFormat
allowing a MapReduce job to run over one or more table snapshots, with one or more scans configured for each. - MultiTableSnapshotInputFormat() - Constructor for class org.apache.hadoop.hbase.mapred.MultiTableSnapshotInputFormat
- MultiTableSnapshotInputFormat() - Constructor for class org.apache.hadoop.hbase.mapreduce.MultiTableSnapshotInputFormat
- org.apache.hadoop.hbase.mapreduce.MultiTableSnapshotInputFormatImpl - Class in org.apache.hadoop.hbase.mapreduce
-
Shared implementation of mapreduce code over multiple table snapshots.
- MultiTableSnapshotInputFormatImpl() - Constructor for class org.apache.hadoop.hbase.mapreduce.MultiTableSnapshotInputFormatImpl
- org.apache.hadoop.hbase.util.MultiThreadedAction - Class in org.apache.hadoop.hbase.util
-
Common base class for reader and writer parts of multi-thread HBase load test (See LoadTestTool).
- MultiThreadedAction(LoadTestDataGenerator, Configuration, TableName, String) - Constructor for class org.apache.hadoop.hbase.util.MultiThreadedAction
- org.apache.hadoop.hbase.util.MultiThreadedAction.DefaultDataGenerator - Class in org.apache.hadoop.hbase.util
-
Default implementation of LoadTestDataGenerator that uses LoadTestKVGenerator, fixed set of column families, and random number of columns in range.
- org.apache.hadoop.hbase.client.example.MultiThreadedClientExample - Class in org.apache.hadoop.hbase.client.example
-
Example on how to use HBase's
Connection
andTable
in a multi-threaded environment. - MultiThreadedClientExample() - Constructor for class org.apache.hadoop.hbase.client.example.MultiThreadedClientExample
- org.apache.hadoop.hbase.client.example.MultiThreadedClientExample.ReadExampleCallable - Class in org.apache.hadoop.hbase.client.example
-
Class to show how to scan some rows starting at a random location.
- org.apache.hadoop.hbase.client.example.MultiThreadedClientExample.SingleWriteExampleCallable - Class in org.apache.hadoop.hbase.client.example
-
Class to show how to send a single put.
- org.apache.hadoop.hbase.client.example.MultiThreadedClientExample.WriteExampleCallable - Class in org.apache.hadoop.hbase.client.example
-
Class that will show how to send batches of puts at the same time.
- org.apache.hadoop.hbase.util.MultiThreadedReader - Class in org.apache.hadoop.hbase.util
-
Creates multiple threads that read and verify previously written data
- MultiThreadedReader(LoadTestDataGenerator, Configuration, TableName, double) - Constructor for class org.apache.hadoop.hbase.util.MultiThreadedReader
- org.apache.hadoop.hbase.util.MultiThreadedReader.HBaseReaderThread - Class in org.apache.hadoop.hbase.util
- org.apache.hadoop.hbase.util.MultiThreadedReaderWithACL - Class in org.apache.hadoop.hbase.util
-
A MultiThreadReader that helps to work with ACL
- MultiThreadedReaderWithACL(LoadTestDataGenerator, Configuration, TableName, double, String) - Constructor for class org.apache.hadoop.hbase.util.MultiThreadedReaderWithACL
- org.apache.hadoop.hbase.util.MultiThreadedReaderWithACL.HBaseReaderThreadWithACL - Class in org.apache.hadoop.hbase.util
- org.apache.hadoop.hbase.mapreduce.MultithreadedTableMapper<K2,
V2> - Class in org.apache.hadoop.hbase.mapreduce -
Multithreaded implementation for @link org.apache.hbase.mapreduce.TableMapper
- MultithreadedTableMapper() - Constructor for class org.apache.hadoop.hbase.mapreduce.MultithreadedTableMapper
- org.apache.hadoop.hbase.util.MultiThreadedUpdater - Class in org.apache.hadoop.hbase.util
-
Creates multiple threads that write key/values into the
- MultiThreadedUpdater(LoadTestDataGenerator, Configuration, TableName, double) - Constructor for class org.apache.hadoop.hbase.util.MultiThreadedUpdater
- org.apache.hadoop.hbase.util.MultiThreadedUpdater.HBaseUpdaterThread - Class in org.apache.hadoop.hbase.util
- org.apache.hadoop.hbase.util.MultiThreadedUpdaterWithACL - Class in org.apache.hadoop.hbase.util
-
A MultiThreadUpdater that helps to work with ACL
- MultiThreadedUpdaterWithACL(LoadTestDataGenerator, Configuration, TableName, double, User, String) - Constructor for class org.apache.hadoop.hbase.util.MultiThreadedUpdaterWithACL
- org.apache.hadoop.hbase.util.MultiThreadedUpdaterWithACL.HBaseUpdaterThreadWithACL - Class in org.apache.hadoop.hbase.util
- org.apache.hadoop.hbase.util.MultiThreadedWriter - Class in org.apache.hadoop.hbase.util
-
Creates multiple threads that write key/values into the
- MultiThreadedWriter(LoadTestDataGenerator, Configuration, TableName) - Constructor for class org.apache.hadoop.hbase.util.MultiThreadedWriter
- org.apache.hadoop.hbase.util.MultiThreadedWriter.HBaseWriterThread - Class in org.apache.hadoop.hbase.util
- org.apache.hadoop.hbase.util.MultiThreadedWriterBase - Class in org.apache.hadoop.hbase.util
-
Creates multiple threads that write key/values into the
- MultiThreadedWriterBase(LoadTestDataGenerator, Configuration, TableName, String) - Constructor for class org.apache.hadoop.hbase.util.MultiThreadedWriterBase
- org.apache.hadoop.hbase.util.MultiThreadedWriterWithACL - Class in org.apache.hadoop.hbase.util
-
MultiThreadedWriter that helps in testing ACL
- MultiThreadedWriterWithACL(LoadTestDataGenerator, Configuration, TableName, User) - Constructor for class org.apache.hadoop.hbase.util.MultiThreadedWriterWithACL
- org.apache.hadoop.hbase.util.MultiThreadedWriterWithACL.HBaseWriterThreadWithACL - Class in org.apache.hadoop.hbase.util
- org.apache.hadoop.hbase.regionserver.MultiVersionConcurrencyControl - Class in org.apache.hadoop.hbase.regionserver
-
Manages the read/write consistency.
- MultiVersionConcurrencyControl() - Constructor for class org.apache.hadoop.hbase.regionserver.MultiVersionConcurrencyControl
- MultiVersionConcurrencyControl(long) - Constructor for class org.apache.hadoop.hbase.regionserver.MultiVersionConcurrencyControl
-
Construct and set read point.
- MultiVersionConcurrencyControl(String) - Constructor for class org.apache.hadoop.hbase.regionserver.MultiVersionConcurrencyControl
- org.apache.hadoop.hbase.regionserver.MultiVersionConcurrencyControl.WriteEntry - Class in org.apache.hadoop.hbase.regionserver
-
Write number and whether write has completed given out at start of a write transaction.
- org.apache.hadoop.hbase.util.MunkresAssignment - Class in org.apache.hadoop.hbase.util
-
Computes the optimal (minimal cost) assignment of jobs to workers (or other analogous) concepts given a cost matrix of each pair of job and worker, using the algorithm by James Munkres in "Algorithms for the Assignment and Transportation Problems", with additional optimizations as described by Jin Kue Wong in "A New Implementation of an Algorithm for the Optimal Assignment Problem: An Improved Version of Munkres' Algorithm".
- MunkresAssignment(float[][]) - Constructor for class org.apache.hadoop.hbase.util.MunkresAssignment
-
Construct a new problem instance with the specified cost matrix.
- MURMUR_HASH - Static variable in class org.apache.hadoop.hbase.util.Hash
-
Constant to denote
MurmurHash
. - MURMUR_HASH3 - Static variable in class org.apache.hadoop.hbase.util.Hash
-
Constant to denote
MurmurHash3
. - org.apache.hadoop.hbase.util.MurmurHash - Class in org.apache.hadoop.hbase.util
-
This is a very fast, non-cryptographic hash suitable for general hash-based lookup.
- MurmurHash() - Constructor for class org.apache.hadoop.hbase.util.MurmurHash
- org.apache.hadoop.hbase.util.MurmurHash3 - Class in org.apache.hadoop.hbase.util
-
This is a very fast, non-cryptographic hash suitable for general hash-based lookup.
- MurmurHash3() - Constructor for class org.apache.hadoop.hbase.util.MurmurHash3
- MUST_PASS_ALL - Enum constant in enum class org.apache.hadoop.hbase.filter.FilterList.Operator
-
!AND
- MUST_PASS_ONE - Enum constant in enum class org.apache.hadoop.hbase.filter.FilterList.Operator
-
!OR
- org.apache.hadoop.hbase.regionserver.MutableOnlineRegions - Interface in org.apache.hadoop.hbase.regionserver
-
Interface to Map of online regions.
- org.apache.hadoop.hbase.regionserver.MutableSegment - Class in org.apache.hadoop.hbase.regionserver
-
A mutable segment in memstore, specifically the active segment.
- MutableSegment(CellSet<ExtendedCell>, CellComparator, MemStoreLAB, MemStoreSizing) - Constructor for class org.apache.hadoop.hbase.regionserver.MutableSegment
- mutate(List<? extends Mutation>) - Method in interface org.apache.hadoop.hbase.client.AsyncBufferedMutator
-
Send some
Mutation
s to the table. - mutate(List<? extends Mutation>) - Method in interface org.apache.hadoop.hbase.client.BufferedMutator
-
Send some
Mutation
s to the table. - mutate(Mutation) - Method in interface org.apache.hadoop.hbase.client.AsyncBufferedMutator
-
Sends a
Mutation
to the table. - mutate(Mutation) - Method in interface org.apache.hadoop.hbase.client.BufferedMutator
-
Sends a
Mutation
to the table. - mutate(Table, Mutation, long) - Method in class org.apache.hadoop.hbase.util.MultiThreadedUpdater.HBaseUpdaterThread
- mutate(Table, Mutation, long) - Method in class org.apache.hadoop.hbase.util.MultiThreadedUpdater
- mutate(Table, Mutation, long, byte[], byte[], byte[], byte[]) - Method in class org.apache.hadoop.hbase.util.MultiThreadedUpdater.HBaseUpdaterThread
- mutate(Table, Mutation, long, byte[], byte[], byte[], byte[]) - Method in class org.apache.hadoop.hbase.util.MultiThreadedUpdater
- mutate(Table, Mutation, long, byte[], byte[], byte[], byte[]) - Method in class org.apache.hadoop.hbase.util.MultiThreadedUpdaterWithACL.HBaseUpdaterThreadWithACL
- mutate(RpcController, ClientProtos.MutateRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
Mutate data in a table.
- MUTATE - Enum constant in enum class org.apache.hadoop.hbase.quotas.OperationQuota.OperationType
- mutateRow(ByteBuffer, ByteBuffer, List<Mutation>, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
- mutateRow(RowMutations) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
Performs multiple mutations atomically on a single row.
- mutateRow(RowMutations) - Method in interface org.apache.hadoop.hbase.client.Table
-
Performs multiple mutations atomically on a single row.
- mutateRow(RowMutations) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
- mutateRow(RowMutations) - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Performs multiple mutations atomically on a single row.
- mutateRow(RowMutations, long, long) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
- mutateRows(ByteBuffer, List<BatchMutation>, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
- mutateRows(RpcController, MultiRowMutationProtos.MutateRowsRequest, RpcCallback<MultiRowMutationProtos.MutateRowsResponse>) - Method in class org.apache.hadoop.hbase.coprocessor.MultiRowMutationEndpoint
- mutateRowsTs(ByteBuffer, List<BatchMutation>, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
- mutateRowsWithLocks(Collection<Mutation>, Collection<byte[]>, long, long) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Perform atomic (all or none) mutations within the region.
- mutateRowsWithLocks(Collection<Mutation>, Collection<byte[]>, long, long) - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Perform atomic mutations within the region.
- mutateRowTs(ByteBuffer, ByteBuffer, List<Mutation>, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
- mutation - Variable in class org.apache.hadoop.hbase.wal.WALSplitUtil.MutationReplay
- org.apache.hadoop.hbase.client.Mutation - Class in org.apache.hadoop.hbase.client
- Mutation() - Constructor for class org.apache.hadoop.hbase.client.Mutation
-
empty construction.
- Mutation(byte[], long, NavigableMap<byte[], List<Cell>>) - Constructor for class org.apache.hadoop.hbase.client.Mutation
-
Construct the mutation with user defined data.
- Mutation(Mutation) - Constructor for class org.apache.hadoop.hbase.client.Mutation
- MUTATION_OVERHEAD - Static variable in class org.apache.hadoop.hbase.client.Mutation
- MutationReplay(ClientProtos.MutationProto.MutationType, Mutation, long, long) - Constructor for class org.apache.hadoop.hbase.wal.WALSplitUtil.MutationReplay
- org.apache.hadoop.hbase.mapreduce.MutationSerialization - Class in org.apache.hadoop.hbase.mapreduce
- MutationSerialization() - Constructor for class org.apache.hadoop.hbase.mapreduce.MutationSerialization
- mvcc - Variable in class org.apache.hadoop.hbase.regionserver.querymatcher.NewVersionBehaviorTracker.DeleteVersionsNode
- MyMapper() - Constructor for class org.apache.hadoop.hbase.ScanPerformanceEvaluation.MyMapper
N
- N - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
ASCII code for 'N'
- name - Variable in class org.apache.hadoop.hbase.errorhandling.ForeignExceptionDispatcher
- name - Variable in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
-
File name to be used for block names
- name - Variable in class org.apache.hadoop.hbase.io.hfile.HFileWriterImpl
-
Name for this object used when logging or in toString.
- NAME - Static variable in class org.apache.hadoop.hbase.HConstants
- NAME - Static variable in class org.apache.hadoop.hbase.mob.mapreduce.MobRefReporter
- NAME - Static variable in class org.apache.hadoop.hbase.replication.CopyReplicationPeers
- NAME - Static variable in class org.apache.hadoop.hbase.snapshot.ExportSnapshot
- NAME_KEY - Static variable in class org.apache.hadoop.hbase.util.JSONMetricUtil
- NAMED_QUEUE_CHORE_DURATION_DEFAULT - Static variable in class org.apache.hadoop.hbase.namequeues.NamedQueueServiceChore
- NAMED_QUEUE_CHORE_DURATION_KEY - Static variable in class org.apache.hadoop.hbase.namequeues.NamedQueueServiceChore
- org.apache.hadoop.hbase.namequeues.request.NamedQueueGetRequest - Class in org.apache.hadoop.hbase.namequeues.request
-
Request object to be used by ring buffer use-cases.
- NamedQueueGetRequest() - Constructor for class org.apache.hadoop.hbase.namequeues.request.NamedQueueGetRequest
- org.apache.hadoop.hbase.namequeues.response.NamedQueueGetResponse - Class in org.apache.hadoop.hbase.namequeues.response
-
Response object to be sent by namedQueue service back to caller
- NamedQueueGetResponse() - Constructor for class org.apache.hadoop.hbase.namequeues.response.NamedQueueGetResponse
- org.apache.hadoop.hbase.namequeues.NamedQueuePayload - Class in org.apache.hadoop.hbase.namequeues
-
Base payload to be prepared by client to send various namedQueue events for in-memory ring buffer storage in either HMaster or RegionServer.
- NamedQueuePayload(int) - Constructor for class org.apache.hadoop.hbase.namequeues.NamedQueuePayload
- org.apache.hadoop.hbase.namequeues.NamedQueuePayload.NamedQueueEvent - Enum Class in org.apache.hadoop.hbase.namequeues
- namedQueueRecorder - Variable in class org.apache.hadoop.hbase.HBaseServerBase
-
Provide online slow log responses from ringbuffer
- org.apache.hadoop.hbase.namequeues.NamedQueueRecorder - Class in org.apache.hadoop.hbase.namequeues
-
NamedQueue recorder that maintains various named queues.
- org.apache.hadoop.hbase.namequeues.NamedQueueService - Interface in org.apache.hadoop.hbase.namequeues
-
In-memory Queue service provider for multiple use-cases.
- org.apache.hadoop.hbase.namequeues.NamedQueueServiceChore - Class in org.apache.hadoop.hbase.namequeues
-
Chore to insert multiple accumulated slow/large logs to hbase:slowlog system table
- NamedQueueServiceChore(Stoppable, int, NamedQueueRecorder, Connection) - Constructor for class org.apache.hadoop.hbase.namequeues.NamedQueueServiceChore
-
Chore Constructor
- NameNodeException(Throwable) - Constructor for exception org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputHelper.NameNodeException
- namespace(String) - Method in class org.apache.hadoop.hbase.client.NormalizeTableFilterParams.Builder
- NAMESPACE - Enum constant in enum class org.apache.hadoop.hbase.hbtop.field.Field
- NAMESPACE - Enum constant in enum class org.apache.hadoop.hbase.hbtop.mode.Mode
- NAMESPACE_COL_DESC_BYTES - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
Deprecated.namespace table has been folded into the ns family in meta table, do not use this any more.
- NAMESPACE_COL_DESC_QUALIFIER - Static variable in class org.apache.hadoop.hbase.HConstants
- NAMESPACE_DELIM - Static variable in class org.apache.hadoop.hbase.TableName
-
Namespace delimiter
- NAMESPACE_DESC_PROP_GROUP - Static variable in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
- NAMESPACE_DESCRIPTOR_COMPARATOR - Static variable in class org.apache.hadoop.hbase.NamespaceDescriptor
- NAMESPACE_FAMILY - Static variable in class org.apache.hadoop.hbase.HConstants
-
The namespace family
- NAMESPACE_FAMILY_INFO - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
Deprecated.namespace table has been folded into the ns family in meta table, do not use this any more.
- NAMESPACE_FAMILY_INFO_BYTES - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
Deprecated.namespace table has been folded into the ns family in meta table, do not use this any more.
- NAMESPACE_FAMILY_STR - Static variable in class org.apache.hadoop.hbase.HConstants
-
The namespace family as a string
- NAMESPACE_TABLE_NAME - Static variable in class org.apache.hadoop.hbase.TableName
-
Deprecated.since 3.0.0 and will be removed in 4.0.0. We have folded the data in namespace table into meta table, so do not use it any more.
- NAMESPACE_TABLEDESC - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
Deprecated.since 3.0.0 and will be removed in 4.0.0. We have folded the data in namespace table into meta table, so do not use it any more.
- org.apache.hadoop.hbase.namespace.NamespaceAuditor - Class in org.apache.hadoop.hbase.namespace
-
The Class NamespaceAuditor performs checks to ensure operations like table creation and region splitting preserve namespace quota.
- NamespaceAuditor(MasterServices) - Constructor for class org.apache.hadoop.hbase.namespace.NamespaceAuditor
- org.apache.hadoop.hbase.NamespaceDescriptor - Class in org.apache.hadoop.hbase
-
Namespace POJO class.
- org.apache.hadoop.hbase.NamespaceDescriptor.Builder - Class in org.apache.hadoop.hbase
- org.apache.hadoop.hbase.NamespaceExistException - Exception in org.apache.hadoop.hbase
-
Thrown when a namespace exists but should not
- NamespaceExistException() - Constructor for exception org.apache.hadoop.hbase.NamespaceExistException
- NamespaceExistException(String) - Constructor for exception org.apache.hadoop.hbase.NamespaceExistException
- org.apache.hadoop.hbase.wal.NamespaceGroupingStrategy - Class in org.apache.hadoop.hbase.wal
-
A WAL grouping strategy based on namespace.
- NamespaceGroupingStrategy() - Constructor for class org.apache.hadoop.hbase.wal.NamespaceGroupingStrategy
- namespaceLock(String, String, Abortable) - Method in class org.apache.hadoop.hbase.client.locking.LockServiceClient
-
LocCreate a new EntityLock object to acquire exclusive lock on a namespace.
- org.apache.hadoop.hbase.hbtop.mode.NamespaceModeStrategy - Class in org.apache.hadoop.hbase.hbtop.mode
-
Implementation for
ModeStrategy
for Namespace Mode. - org.apache.hadoop.hbase.NamespaceNotFoundException - Exception in org.apache.hadoop.hbase
-
Thrown when a namespace can not be located
- NamespaceNotFoundException() - Constructor for exception org.apache.hadoop.hbase.NamespaceNotFoundException
- NamespaceNotFoundException(String) - Constructor for exception org.apache.hadoop.hbase.NamespaceNotFoundException
- org.apache.hadoop.hbase.quotas.NamespaceQuotaSnapshotStore - Class in org.apache.hadoop.hbase.quotas
-
QuotaSnapshotStore
implementation for namespaces. - NamespaceQuotaSnapshotStore(Connection, QuotaObserverChore, Map<RegionInfo, Long>) - Constructor for class org.apache.hadoop.hbase.quotas.NamespaceQuotaSnapshotStore
- org.apache.hadoop.hbase.rest.NamespacesInstanceResource - Class in org.apache.hadoop.hbase.rest
-
Implements the following REST end points:
- NamespacesInstanceResource(String) - Constructor for class org.apache.hadoop.hbase.rest.NamespacesInstanceResource
-
Constructor for standard NamespaceInstanceResource.
- NamespacesInstanceResource(String, boolean) - Constructor for class org.apache.hadoop.hbase.rest.NamespacesInstanceResource
-
Constructor for querying namespace table list via NamespaceInstanceResource.
- org.apache.hadoop.hbase.rest.NamespacesResource - Class in org.apache.hadoop.hbase.rest
-
Implements REST GET list of all namespaces.
- NamespacesResource() - Constructor for class org.apache.hadoop.hbase.rest.NamespacesResource
-
Constructor
- org.apache.hadoop.hbase.replication.NamespaceTableCfWALEntryFilter - Class in org.apache.hadoop.hbase.replication
-
Filter a WAL Entry by the peer config according to the table and family which it belongs to.
- NamespaceTableCfWALEntryFilter(ReplicationPeer) - Constructor for class org.apache.hadoop.hbase.replication.NamespaceTableCfWALEntryFilter
- nameToType(String) - Static method in enum class org.apache.hadoop.hbase.util.ChecksumType
-
Map a checksum name to a specific type.
- NANOS_PER_SECOND - Static variable in class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil
- navigableKeySet() - Method in class org.apache.hadoop.hbase.regionserver.CellFlatMap
- navigableKeySet() - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
- NB_SEND - Static variable in class org.apache.hadoop.hbase.master.ClusterStatusPublisher
-
If a server dies, we're sending the information multiple times in case a receiver misses the message.
- NEED - Enum constant in enum class org.apache.hadoop.hbase.io.crypto.tls.X509Util.ClientAuth
- needAuthorization() - Method in class org.apache.hadoop.hbase.ipc.RpcServer
- needsClientAuth(boolean) - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
-
Specify whether the server should authorize the client in SSL connections.
- needsCompaction() - Method in class org.apache.hadoop.hbase.regionserver.HStore
- needsCompaction() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
See if there's too much store files in this store
- needsCompaction(List<HStoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.DateTieredStoreEngine
- needsCompaction(List<HStoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.DefaultStoreEngine
- needsCompaction(List<HStoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.StoreEngine
- needsCompaction(List<HStoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreEngine
- needsPeriodicRoll(long) - Method in class org.apache.hadoop.hbase.wal.AbstractWALRoller.RollController
- needsQuoting(byte[], int, int) - Static method in class org.apache.hadoop.hbase.http.HtmlQuoting
-
Does the given string need to be quoted?
- needsQuoting(String) - Static method in class org.apache.hadoop.hbase.http.HtmlQuoting
-
Does the given string need to be quoted?
- needsRoll(long) - Method in class org.apache.hadoop.hbase.wal.AbstractWALRoller.RollController
- needsTaskCommit(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputCommitter
- needsTuning() - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerResult
- needToReplicate(TableName) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
-
Decide whether the table need replicate to the peer cluster
- needToReplicate(TableName, byte[]) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
-
Decide whether the passed family of the table need replicate to the peer cluster according to this peer config.
- NEGOTIATE - Static variable in class org.apache.hadoop.hbase.thrift.ThriftHttpServlet
- NETTY_DM_USAGE_DESC - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
- NETTY_DM_USAGE_NAME - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
- NETTY_MAX_PENDING_OUTBOUND_DESC - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
- NETTY_MAX_PENDING_OUTBOUND_NAME - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
- NETTY_NATIVETRANSPORT_KEY - Static variable in class org.apache.hadoop.hbase.util.NettyEventLoopGroupConfig
- NETTY_TOTAL_PENDING_OUTBOUND_DESC - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
- NETTY_TOTAL_PENDING_OUTBOUND_NAME - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
- NETTY_WORKER_COUNT_KEY - Static variable in class org.apache.hadoop.hbase.util.NettyEventLoopGroupConfig
- org.apache.hadoop.hbase.wal.NettyAsyncFSWALConfigHelper - Class in org.apache.hadoop.hbase.wal
-
Helper class for passing netty event loop config to
AsyncFSWALProvider
. - org.apache.hadoop.hbase.util.NettyEventLoopGroupConfig - Class in org.apache.hadoop.hbase.util
-
Event loop group related config.
- NettyEventLoopGroupConfig(Configuration, String) - Constructor for class org.apache.hadoop.hbase.util.NettyEventLoopGroupConfig
- org.apache.hadoop.hbase.util.NettyFutureUtils - Class in org.apache.hadoop.hbase.util
-
Helper class for processing netty futures.
- org.apache.hadoop.hbase.security.NettyHBaseRpcConnectionHeaderHandler - Class in org.apache.hadoop.hbase.security
-
Implement logic to deal with the rpc connection header.
- NettyHBaseRpcConnectionHeaderHandler(Promise<Boolean>, Configuration, ByteBuf) - Constructor for class org.apache.hadoop.hbase.security.NettyHBaseRpcConnectionHeaderHandler
- org.apache.hadoop.hbase.security.NettyHBaseSaslRpcClient - Class in org.apache.hadoop.hbase.security
-
Implement SASL logic for netty rpc client.
- NettyHBaseSaslRpcClient(Configuration, SaslClientAuthenticationProvider, Token<? extends TokenIdentifier>, InetAddress, String, boolean, String) - Constructor for class org.apache.hadoop.hbase.security.NettyHBaseSaslRpcClient
- org.apache.hadoop.hbase.security.NettyHBaseSaslRpcClientHandler - Class in org.apache.hadoop.hbase.security
-
Implement SASL logic for netty rpc client.
- NettyHBaseSaslRpcClientHandler(Promise<Boolean>, UserGroupInformation, SaslClientAuthenticationProvider, Token<? extends TokenIdentifier>, InetAddress, String, boolean, Configuration) - Constructor for class org.apache.hadoop.hbase.security.NettyHBaseSaslRpcClientHandler
- org.apache.hadoop.hbase.ipc.NettyRpcClient - Class in org.apache.hadoop.hbase.ipc
-
Netty client for the requests and responses.
- NettyRpcClient(Configuration) - Constructor for class org.apache.hadoop.hbase.ipc.NettyRpcClient
-
Used in test only.
- NettyRpcClient(Configuration, String, SocketAddress, MetricsConnection) - Constructor for class org.apache.hadoop.hbase.ipc.NettyRpcClient
- NettyRpcClient(Configuration, String, SocketAddress, MetricsConnection, Map<String, byte[]>) - Constructor for class org.apache.hadoop.hbase.ipc.NettyRpcClient
- org.apache.hadoop.hbase.ipc.NettyRpcClientConfigHelper - Class in org.apache.hadoop.hbase.ipc
-
Helper class for passing config to
NettyRpcClient
. - org.apache.hadoop.hbase.ipc.NettyRpcServer - Class in org.apache.hadoop.hbase.ipc
-
An RPC server with Netty4 implementation.
- NettyRpcServer(Server, String, List<RpcServer.BlockingServiceAndInterface>, InetSocketAddress, Configuration, RpcScheduler, boolean) - Constructor for class org.apache.hadoop.hbase.ipc.NettyRpcServer
- org.apache.hadoop.hbase.ipc.NettyRpcServerChannelWritabilityHandler - Class in org.apache.hadoop.hbase.ipc
-
Handler to enforce writability protections on our server channels:
- Responds to channel writability events, which are triggered when the total pending bytes for a channel passes configured high and low watermarks. - org.apache.hadoop.hbase.util.NettyUnsafeUtils - Class in org.apache.hadoop.hbase.util
-
Wraps some usages of netty's unsafe API, for ease of maintainability.
- NEW - Enum constant in enum class org.apache.hadoop.hbase.io.FileChangeWatcher.State
- NEW_SYNC_REPLICATION_STATE_ZNODE - Static variable in class org.apache.hadoop.hbase.replication.ZKReplicationPeerStorage
- NEW_VERSION_BEHAVIOR - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
- newBlock() - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterImpl
-
Ready a new block for writing.
- newBuilder() - Static method in class org.apache.hadoop.hbase.client.BalanceRequest
-
Create a builder to construct a custom
BalanceRequest
. - newBuilder() - Static method in class org.apache.hadoop.hbase.client.BalanceResponse
-
Creates a new
BalanceResponse.Builder
- newBuilder() - Static method in class org.apache.hadoop.hbase.ClusterMetricsBuilder
- newBuilder() - Static method in class org.apache.hadoop.hbase.regionserver.ScannerContext
- newBuilder() - Static method in class org.apache.hadoop.hbase.replication.ReplicationLoadSink
- newBuilder() - Static method in class org.apache.hadoop.hbase.replication.ReplicationLoadSource
- newBuilder() - Static method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
- newBuilder() - Static method in class org.apache.hadoop.hbase.ServerTaskBuilder
- newBuilder(boolean) - Static method in class org.apache.hadoop.hbase.regionserver.ScannerContext
- newBuilder(byte[]) - Static method in class org.apache.hadoop.hbase.client.CheckAndMutate
-
returns a builder object to build a CheckAndMutate object
- newBuilder(byte[]) - Static method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
- newBuilder(byte[]) - Static method in class org.apache.hadoop.hbase.RegionMetricsBuilder
- newBuilder(byte[]) - Static method in class org.apache.hadoop.hbase.UserMetricsBuilder
- newBuilder(String) - Static method in class org.apache.hadoop.hbase.client.CoprocessorDescriptorBuilder
- newBuilder(ColumnFamilyDescriptor) - Static method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
- newBuilder(RegionInfo) - Static method in class org.apache.hadoop.hbase.client.RegionInfoBuilder
- newBuilder(TableDescriptor) - Static method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
Copy all values, families, and name from the input.
- newBuilder(Field) - Static method in class org.apache.hadoop.hbase.hbtop.RecordFilter
- newBuilder(Field, boolean) - Static method in class org.apache.hadoop.hbase.hbtop.RecordFilter
- newBuilder(ReaderContext) - Static method in class org.apache.hadoop.hbase.io.hfile.ReaderContextBuilder
- newBuilder(ReplicationPeerConfig) - Static method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
- newBuilder(ServerName) - Static method in class org.apache.hadoop.hbase.ServerMetricsBuilder
- newBuilder(TableName) - Static method in class org.apache.hadoop.hbase.client.RegionInfoBuilder
- newBuilder(TableName) - Static method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
- newCallStats() - Static method in class org.apache.hadoop.hbase.client.MetricsConnection
-
Produce an instance of
MetricsConnection.CallStats
for clients to attach to RPCs. - newChecker() - Method in interface org.apache.hadoop.hbase.client.RequestController
-
Returns A new checker for evaluating a batch rows.
- newContext() - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
- newContext(Configuration) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
- newController() - Method in class org.apache.hadoop.hbase.ipc.RpcControllerFactory
- newController(List<ExtendedCellScannable>) - Method in class org.apache.hadoop.hbase.ipc.RpcControllerFactory
- newController(RegionInfo, List<ExtendedCellScannable>) - Method in class org.apache.hadoop.hbase.ipc.RpcControllerFactory
- newController(RegionInfo, ExtendedCellScanner) - Method in class org.apache.hadoop.hbase.ipc.RpcControllerFactory
- newController(ExtendedCellScanner) - Method in class org.apache.hadoop.hbase.ipc.RpcControllerFactory
- newDataBlockDecodingContext(Configuration, HFileContext) - Method in class org.apache.hadoop.hbase.io.encoding.AbstractDataBlockEncoder
- newDataBlockDecodingContext(Configuration, HFileContext) - Method in interface org.apache.hadoop.hbase.io.encoding.DataBlockEncoder
-
Creates an encoder specific decoding context, which will prepare the data before actual decoding store configuration HFile meta data
- newDataBlockDecodingContext(Configuration, HFileContext) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoder
-
create a encoder specific decoding context for reading.
- newDataBlockDecodingContext(Configuration, HFileContext) - Method in class org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoderImpl
- newDataBlockDecodingContext(Configuration, HFileContext) - Method in class org.apache.hadoop.hbase.io.hfile.NoOpDataBlockEncoder
- newDataBlockEncodingContext(Configuration, byte[], HFileContext) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoder
-
Create an encoder specific encoding context object for writing.
- newDataBlockEncodingContext(Configuration, byte[], HFileContext) - Method in class org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoderImpl
- newDataBlockEncodingContext(Configuration, byte[], HFileContext) - Method in class org.apache.hadoop.hbase.io.hfile.NoOpDataBlockEncoder
- newDataBlockEncodingContext(Configuration, DataBlockEncoding, byte[], HFileContext) - Method in class org.apache.hadoop.hbase.io.encoding.AbstractDataBlockEncoder
- newDataBlockEncodingContext(Configuration, DataBlockEncoding, byte[], HFileContext) - Method in interface org.apache.hadoop.hbase.io.encoding.DataBlockEncoder
-
Creates a encoder specific encoding context store configuration encoding strategy used header bytes to be written, put a dummy header here if the header is unknown HFile meta data
- newDirectBuffer(int, int) - Method in class org.apache.hadoop.hbase.ipc.HeapByteBufAllocator
- newHeapBuffer(int, int) - Method in class org.apache.hadoop.hbase.ipc.HeapByteBufAllocator
- newHistogram(Reservoir) - Static method in class org.apache.hadoop.hbase.util.YammerHistogramUtils
-
Create a new
Histogram
instance. - newHRegion(Path, WAL, FileSystem, Configuration, RegionInfo, TableDescriptor, RegionServerServices) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
-
A utility method to create new instances of HRegion based on the
HConstants.REGION_IMPL
configuration property. - newInstance(Class<T>, Object...) - Static method in class org.apache.hadoop.hbase.util.ReflectionUtils
- newInstance(String, Object...) - Static method in class org.apache.hadoop.hbase.util.ReflectionUtils
- newInstance(Configuration) - Static method in interface org.apache.hadoop.hbase.regionserver.MemStoreLAB
- newInstance(Hbase.Iface, ThriftMetrics, Configuration) - Static method in class org.apache.hadoop.hbase.thrift.HbaseHandlerMetricsProxy
- newInstance(THBaseService.Iface, ThriftMetrics, Configuration) - Static method in class org.apache.hadoop.hbase.thrift.HbaseHandlerMetricsProxy
- newKVHeap(List<? extends KeyValueScanner>, CellComparator) - Method in class org.apache.hadoop.hbase.regionserver.ReversedStoreScanner
- newKVHeap(List<? extends KeyValueScanner>, CellComparator) - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
- newNonce() - Method in interface org.apache.hadoop.hbase.client.NonceGenerator
-
Returns New nonce.
- newNonce() - Method in class org.apache.hadoop.hbase.client.PerClientRandomNonceGenerator
- newPair(T1, T2) - Static method in class org.apache.hadoop.hbase.util.Pair
-
Constructs a new pair, inferring the type via the passed arguments
- newParser() - Method in class org.apache.hadoop.hbase.mapreduce.RowCounter
- newParser() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo
- newParser() - Method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
-
Create the parser to use for parsing and validating the command line.
- newParser() - Method in class org.apache.hadoop.hbase.util.LoadTestTool
- newReader(Configuration, ImmutableBytesWritable) - Method in class org.apache.hadoop.hbase.mapreduce.HashTable.TableHash
-
Open a TableHash.Reader starting at the first hash at or after the given key.
- newServiceStub(Class<T>, RpcChannel) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
- newSplitAlgoInstance(Configuration, String) - Static method in class org.apache.hadoop.hbase.util.RegionSplitter
- newValue(Object) - Method in enum class org.apache.hadoop.hbase.hbtop.field.Field
- org.apache.hadoop.hbase.regionserver.querymatcher.NewVersionBehaviorTracker - Class in org.apache.hadoop.hbase.regionserver.querymatcher
-
A tracker both implementing ColumnTracker and DeleteTracker, used for mvcc-sensitive scanning.
- NewVersionBehaviorTracker(NavigableSet<byte[]>, CellComparator, int, int, int, long) - Constructor for class org.apache.hadoop.hbase.regionserver.querymatcher.NewVersionBehaviorTracker
-
Note maxVersion and minVersion must set according to cf's conf, not user's scan parameter.
- org.apache.hadoop.hbase.regionserver.querymatcher.NewVersionBehaviorTracker.DeleteVersionsNode - Class in org.apache.hadoop.hbase.regionserver.querymatcher
-
A data structure which contains infos we need that happens before this node's mvcc and after the previous node's mvcc.
- next() - Method in class org.apache.hadoop.hbase.client.ClientSideRegionScanner
- next() - Method in interface org.apache.hadoop.hbase.client.ResultScanner
-
Grab the next row's worth of values.
- next() - Method in class org.apache.hadoop.hbase.client.TableSnapshotScanner
- next() - Method in interface org.apache.hadoop.hbase.io.encoding.DataBlockEncoder.EncodedSeeker
-
Move to next position
- next() - Method in class org.apache.hadoop.hbase.io.encoding.RowIndexSeekerV1
- next() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.EncodedScanner
- next() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
-
Go to the next key/value in the block section.
- next() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
-
Scans to the next entry in the file.
- next() - Method in class org.apache.hadoop.hbase.mapreduce.HashTable.TableHash.Reader
-
Read the next key/hash pair.
- next() - Method in class org.apache.hadoop.hbase.quotas.QuotaRetriever
- next() - Method in class org.apache.hadoop.hbase.regionserver.KeyValueHeap
- next() - Method in interface org.apache.hadoop.hbase.regionserver.KeyValueScanner
-
Return the next Cell in this scanner, iterating the scanner
- next() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreCompactorSegmentsIterator
- next() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreMergerSegmentsIterator
- next() - Method in class org.apache.hadoop.hbase.regionserver.ReversedKeyValueHeap
- next() - Method in class org.apache.hadoop.hbase.regionserver.SegmentScanner
-
Return the next Cell in this scanner, iterating the scanner
- next() - Method in class org.apache.hadoop.hbase.regionserver.SnapshotSegmentScanner
- next() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
- next() - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
- next() - Method in interface org.apache.hadoop.hbase.replication.ZKReplicationQueueStorageForMigration.MigrationIterator
- next() - Method in class org.apache.hadoop.hbase.rest.RowResultGenerator
- next() - Method in class org.apache.hadoop.hbase.rest.ScannerResultGenerator
- next() - Method in class org.apache.hadoop.hbase.types.StructIterator
- next() - Method in class org.apache.hadoop.hbase.util.AvlUtil.AvlTreeIterator
- next() - Method in class org.apache.hadoop.hbase.util.CollectionBackedScanner
- next() - Method in class org.apache.hadoop.hbase.util.ConcatenatedLists.Iterator
- next() - Method in interface org.apache.hadoop.hbase.wal.WALStreamReader
-
Read the next entry in WAL.
- next(int) - Method in interface org.apache.hadoop.hbase.client.ResultScanner
-
Get nbRows rows.
- next(long) - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufWALTailingReader
- next(long) - Method in interface org.apache.hadoop.hbase.wal.WALTailingReader
-
Read the next entry and make sure the position after reading does not go beyond the given
limit
. - next(List<? super ExtendedCell>) - Method in interface org.apache.hadoop.hbase.regionserver.InternalScanner
-
Grab the next row's worth of values.
- next(List<? super ExtendedCell>, ScannerContext) - Method in interface org.apache.hadoop.hbase.regionserver.InternalScanner
-
Grab the next row's worth of values.
- next(List<? super ExtendedCell>, ScannerContext) - Method in class org.apache.hadoop.hbase.regionserver.KeyValueHeap
-
Gets the next row of keys from the top-most scanner.
- next(List<? super ExtendedCell>, ScannerContext) - Method in class org.apache.hadoop.hbase.regionserver.MobStoreScanner
-
Firstly reads the cells from the HBase.
- next(List<? super ExtendedCell>, ScannerContext) - Method in class org.apache.hadoop.hbase.regionserver.ReversedMobStoreScanner
-
Firstly reads the cells from the HBase.
- next(List<? super ExtendedCell>, ScannerContext) - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
Get the next row of values from this Store.
- next(ImmutableBytesWritable, Result) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
- next(ImmutableBytesWritable, Result) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
- next(WAL.Entry) - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufWALStreamReader
- next(WAL.Entry) - Method in interface org.apache.hadoop.hbase.wal.WALStreamReader
-
Read the next entry in WAL, use the given
WAL.Entry
if notnull
to hold the data. - NEXT - Enum constant in enum class org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher.MatchCode
-
Do not include, jump to next StoreFile or memstore (in time order)
- NEXT_BIT_MASK - Static variable in class org.apache.hadoop.hbase.util.ByteBufferUtils
- NEXT_BIT_SHIFT - Static variable in class org.apache.hadoop.hbase.util.ByteBufferUtils
- NEXT_COL - Enum constant in enum class org.apache.hadoop.hbase.filter.Filter.ReturnCode
-
Skip this column.
- NEXT_ROW - Enum constant in enum class org.apache.hadoop.hbase.filter.Filter.ReturnCode
-
Seek to next row in current family.
- nextBytes(byte[]) - Method in class org.apache.hadoop.hbase.util.Random64
- nextFreeOffset - Variable in class org.apache.hadoop.hbase.regionserver.Chunk
-
Offset for the next allocation, or the sentinel value -1 which implies that the chunk is still uninitialized.
- nextIndexedKey - Variable in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
-
The next indexed key is to keep track of the indexed key of the next data block.
- nextInt() - Method in class org.apache.hadoop.hbase.util.RandomDistribution.Binomial
- nextInt() - Method in interface org.apache.hadoop.hbase.util.RandomDistribution.DiscreteRNG
-
Get the next random number
- nextInt() - Method in class org.apache.hadoop.hbase.util.RandomDistribution.Flat
- nextInt() - Method in class org.apache.hadoop.hbase.util.RandomDistribution.Zipf
- nextKeyToWrite - Variable in class org.apache.hadoop.hbase.util.MultiThreadedWriterBase
-
This is the current key to be inserted/updated by any thread.
- nextKeyValue() - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReader
-
Positions the record reader to the next record.
- nextKeyValue() - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReaderImpl
-
Positions the record reader to the next record.
- nextKeyValue() - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.RecordReader
- nextLong() - Method in class org.apache.hadoop.hbase.util.Random64
- nextRaw(List<? super ExtendedCell>) - Method in interface org.apache.hadoop.hbase.regionserver.RegionScanner
-
Grab the next row's worth of values.
- nextRaw(List<? super ExtendedCell>, ScannerContext) - Method in interface org.apache.hadoop.hbase.regionserver.RegionScanner
-
Grab the next row's worth of values.
- nextShallowCopy(ByteBuffer, boolean, boolean) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
-
Creates a new KeyValue object positioned in the supplied ByteBuffer and sets the ByteBuffer's position to the start of the next KeyValue.
- nextWasCalled - Variable in class org.apache.hadoop.hbase.util.ConcatenatedLists.Iterator
- NINE - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
ASCII code foe Nine
- NINES - Static variable in class org.apache.hadoop.hbase.HConstants
- NINETIETH_PERCENTILE_METRIC_NAME - Static variable in interface org.apache.hadoop.metrics2.MetricHistogram
- NINETY_EIGHTH_PERCENTILE_METRIC_NAME - Static variable in interface org.apache.hadoop.metrics2.MetricHistogram
- NINETY_FIFTH_PERCENTILE_METRIC_NAME - Static variable in interface org.apache.hadoop.metrics2.MetricHistogram
- NINETY_NINE_POINT_NINETH_PERCENTILE_METRIC_NAME - Static variable in interface org.apache.hadoop.metrics2.MetricHistogram
- NINETY_NINETH_PERCENTILE_METRIC_NAME - Static variable in interface org.apache.hadoop.metrics2.MetricHistogram
- NIO_BUFFER_LIMIT - Static variable in class org.apache.hadoop.hbase.ipc.RpcServer
-
When the read or write buffer size is larger than this limit, i/o will be done in chunks of this size.
- nioByteBuffers() - Method in class org.apache.hadoop.hbase.nio.ByteBuff
- nioByteBuffers() - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
- nioByteBuffers() - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
- NO_CACHE_FILTER - Static variable in class org.apache.hadoop.hbase.http.HttpServer
- NO_HASH - Static variable in class org.apache.hadoop.hbase.client.RegionInfoBuilder
- NO_INSERTS - Enum constant in enum class org.apache.hadoop.hbase.quotas.SpaceViolationPolicy
-
Disallows any updates (but allows deletes and compactions) on the table(s).
- NO_META_REGION - Enum constant in enum class org.apache.hadoop.hbase.util.HbckErrorReporter.ERROR_CODE
-
Deprecated.
- NO_MORE_VALUES - Enum constant in enum class org.apache.hadoop.hbase.regionserver.ScannerContext.NextState
- NO_NEXT_INDEXED_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.KeyValueScanner
-
The byte array represents for NO_NEXT_INDEXED_KEY; The actual value is irrelevant because this is always compared by reference.
- NO_NONCE - Static variable in class org.apache.hadoop.hbase.HConstants
- NO_OP - Enum constant in enum class org.apache.hadoop.hbase.CompareOperator
-
no operation
- NO_PRIORITY - Static variable in interface org.apache.hadoop.hbase.regionserver.Store
- NO_QUOTA - Static variable in interface org.apache.hadoop.hbase.quotas.QuotaSnapshotStore
-
Singleton to represent a table without a quota defined.
- NO_SEQNUM - Static variable in class org.apache.hadoop.hbase.HConstants
-
Value indicating the server name was saved with no sequence number.
- NO_SEQUENCE_ID - Static variable in interface org.apache.hadoop.hbase.regionserver.SequenceId
-
Used to represent when a particular wal key doesn't know/care about the sequence ordering.
- NO_SNAPSHOT_START_TIME_SPECIFIED - Static variable in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
Default value if no start time is specified
- NO_STORE - Static variable in class org.apache.hadoop.hbase.http.NoCacheFilter
-
Constant for the configuration property that indicates no-store cache control is enabled.
- NO_STRICT_COL_FAMILY - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv
- NO_TABLE_STATE - Enum constant in enum class org.apache.hadoop.hbase.util.HbckErrorReporter.ERROR_CODE
-
Deprecated.
- NO_TABLEINFO_FILE - Enum constant in enum class org.apache.hadoop.hbase.util.HbckErrorReporter.ERROR_CODE
-
Deprecated.
- NO_VERSION_FILE - Enum constant in enum class org.apache.hadoop.hbase.util.HbckErrorReporter.ERROR_CODE
-
Deprecated.
- NO_WRITES - Enum constant in enum class org.apache.hadoop.hbase.quotas.SpaceViolationPolicy
-
Disallows any mutations (but allows compactions) on the table(s).
- NO_WRITES_COMPACTIONS - Enum constant in enum class org.apache.hadoop.hbase.quotas.SpaceViolationPolicy
-
Disallows any mutations or compactions on the table(s).
- NoBackoffPolicy(Configuration) - Constructor for class org.apache.hadoop.hbase.client.backoff.ClientBackoffPolicyFactory.NoBackoffPolicy
- NOCACHE_PARAM_NAME - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
If this query parameter is present when processing row or scanner resources, it disables server side block caching
- org.apache.hadoop.hbase.http.NoCacheFilter - Class in org.apache.hadoop.hbase.http
- NoCacheFilter() - Constructor for class org.apache.hadoop.hbase.http.NoCacheFilter
- node - Variable in class org.apache.hadoop.hbase.zookeeper.ZKNodeTracker
-
Path of node being tracked
- NodeAndData(String, byte[]) - Constructor for class org.apache.hadoop.hbase.zookeeper.ZKUtil.NodeAndData
-
Deprecated.
- nodeChildrenChanged(String) - Method in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination
-
Override handler from
ZKListener
- nodeChildrenChanged(String) - Method in class org.apache.hadoop.hbase.master.ActiveMasterManager
- nodeChildrenChanged(String) - Method in class org.apache.hadoop.hbase.master.DrainingServerTracker
- nodeChildrenChanged(String) - Method in class org.apache.hadoop.hbase.master.RegionServerTracker
- nodeChildrenChanged(String) - Method in class org.apache.hadoop.hbase.MetaRegionLocationCache
- nodeChildrenChanged(String) - Method in class org.apache.hadoop.hbase.zookeeper.MasterAddressTracker
- nodeChildrenChanged(String) - Method in class org.apache.hadoop.hbase.zookeeper.MasterMaintenanceModeTracker
- nodeChildrenChanged(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZKListener
-
Called when an existing node has a child node added or removed.
- nodeCreated(String) - Method in class org.apache.hadoop.hbase.master.ActiveMasterManager
- nodeCreated(String) - Method in class org.apache.hadoop.hbase.MetaRegionLocationCache
- nodeCreated(String) - Method in class org.apache.hadoop.hbase.zookeeper.MasterMaintenanceModeTracker
- nodeCreated(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZKLeaderManager
-
Deprecated.
- nodeCreated(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZKListener
-
Called when a new node has been created.
- nodeCreated(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZKNodeTracker
- nodeDataChanged(String) - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
- nodeDataChanged(String) - Method in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination
-
Override handler from
ZKListener
- nodeDataChanged(String) - Method in class org.apache.hadoop.hbase.MetaRegionLocationCache
- nodeDataChanged(String) - Method in class org.apache.hadoop.hbase.zookeeper.DeletionListener
- nodeDataChanged(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZKListener
-
Called when an existing node has changed data.
- nodeDataChanged(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZKNodeTracker
- nodeDeleted(String) - Method in class org.apache.hadoop.hbase.master.ActiveMasterManager
- nodeDeleted(String) - Method in class org.apache.hadoop.hbase.master.DrainingServerTracker
- nodeDeleted(String) - Method in class org.apache.hadoop.hbase.MetaRegionLocationCache
- nodeDeleted(String) - Method in class org.apache.hadoop.hbase.zookeeper.DeletionListener
- nodeDeleted(String) - Method in class org.apache.hadoop.hbase.zookeeper.MasterMaintenanceModeTracker
- nodeDeleted(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZKLeaderManager
-
Deprecated.
- nodeDeleted(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZKListener
-
Called when a node has been deleted
- nodeDeleted(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZKNodeTracker
- nodeHasChildren(ZKWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Checks if the specified znode has any children.
- nodes - Variable in class org.apache.hadoop.hbase.rest.client.Cluster
- org.apache.hadoop.hbase.quotas.policies.NoInsertsViolationPolicyEnforcement - Class in org.apache.hadoop.hbase.quotas.policies
-
A
SpaceViolationPolicyEnforcement
which disallows any inserts to the table. - NoInsertsViolationPolicyEnforcement() - Constructor for class org.apache.hadoop.hbase.quotas.policies.NoInsertsViolationPolicyEnforcement
- org.apache.hadoop.hbase.regionserver.NoLimitScannerContext - Class in org.apache.hadoop.hbase.regionserver
-
This is a special
ScannerContext
subclass that is designed to be used globally when limits should not be enforced during invocations ofInternalScanner.next(java.util.List)
orInternalScanner.next(java.util.List)
. - NoLimitScannerContext() - Constructor for class org.apache.hadoop.hbase.regionserver.NoLimitScannerContext
- org.apache.hadoop.hbase.regionserver.throttle.NoLimitThroughputController - Class in org.apache.hadoop.hbase.regionserver.throttle
- NoLimitThroughputController() - Constructor for class org.apache.hadoop.hbase.regionserver.throttle.NoLimitThroughputController
- NON_META_FILTER - Static variable in class org.apache.hadoop.hbase.master.MasterWalManager
-
Filter *out* WAL files that are for the hbase:meta Region; i.e.
- NON_STARTCODE - Static variable in class org.apache.hadoop.hbase.ServerName
-
What to use if no startcode supplied.
- NON_SYNC - Enum constant in enum class org.apache.hadoop.hbase.regionserver.TimeRangeTracker.Type
- NON_SYNC_TIMERANGE_TRACKER - Static variable in class org.apache.hadoop.hbase.util.ClassSize
-
Overhead for NonSyncTimeRangeTracker
- NONBLOCKING - Enum constant in enum class org.apache.hadoop.hbase.thrift.ImplType
- nonce - Variable in class org.apache.hadoop.hbase.wal.WALSplitUtil.MutationReplay
- org.apache.hadoop.hbase.client.NonceGenerator - Interface in org.apache.hadoop.hbase.client
-
NonceGenerator interface.
- nonceGroup - Variable in class org.apache.hadoop.hbase.wal.WALSplitUtil.MutationReplay
- org.apache.hadoop.hbase.util.NonceKey - Class in org.apache.hadoop.hbase.util
-
This implementation is not smart and just treats nonce group and nonce as random bits.
- NonceKey(long, long) - Constructor for class org.apache.hadoop.hbase.util.NonceKey
- NONE - Enum constant in enum class org.apache.hadoop.hbase.CatalogReplicaMode
- NONE - Enum constant in enum class org.apache.hadoop.hbase.client.CompactionState
- NONE - Enum constant in enum class org.apache.hadoop.hbase.io.compress.Compression.Algorithm
- NONE - Enum constant in enum class org.apache.hadoop.hbase.io.crypto.tls.X509Util.ClientAuth
- NONE - Enum constant in enum class org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
-
Disable data block encoding.
- NONE - Enum constant in enum class org.apache.hadoop.hbase.io.encoding.IndexBlockEncoding
-
Disable index block encoding.
- NONE - Enum constant in enum class org.apache.hadoop.hbase.MemoryCompactionPolicy
-
No memory compaction, when size threshold is exceeded data is flushed to disk
- NONE - Enum constant in enum class org.apache.hadoop.hbase.regionserver.BloomType
-
Bloomfilters disabled
- NONE - Enum constant in enum class org.apache.hadoop.hbase.replication.SyncReplicationState
- NONE - Enum constant in enum class org.apache.hadoop.hbase.util.PrettyPrinter.Unit
- NONE - Static variable in class org.apache.hadoop.hbase.io.ByteBuffAllocator
- NONE - Static variable in class org.apache.hadoop.hbase.io.crypto.Encryption.Context
-
The null crypto context
- NONE - Static variable in class org.apache.hadoop.hbase.regionserver.MultiVersionConcurrencyControl
-
Represents no value, or not set.
- NONE_STATE_ZNODE_BYTES - Static variable in class org.apache.hadoop.hbase.replication.ZKReplicationPeerStorage
- org.apache.hadoop.hbase.io.encoding.NoneEncoder - Class in org.apache.hadoop.hbase.io.encoding
- NoneEncoder(DataOutputStream, HFileBlockDefaultEncodingContext) - Constructor for class org.apache.hadoop.hbase.io.encoding.NoneEncoder
- org.apache.hadoop.hbase.regionserver.NonLazyKeyValueScanner - Class in org.apache.hadoop.hbase.regionserver
-
A "non-lazy" scanner which always does a real seek operation.
- NonLazyKeyValueScanner() - Constructor for class org.apache.hadoop.hbase.regionserver.NonLazyKeyValueScanner
- org.apache.hadoop.hbase.regionserver.NonReversedNonLazyKeyValueScanner - Class in org.apache.hadoop.hbase.regionserver
-
A "non-reversed & non-lazy" scanner which does not support backward scanning and always does a real seek operation.
- NonReversedNonLazyKeyValueScanner() - Constructor for class org.apache.hadoop.hbase.regionserver.NonReversedNonLazyKeyValueScanner
- NOOP - Enum constant in enum class org.apache.hadoop.hbase.regionserver.MemStoreCompactionStrategy.Action
- org.apache.hadoop.hbase.io.hfile.NoOpDataBlockEncoder - Class in org.apache.hadoop.hbase.io.hfile
-
Does not perform any kind of encoding/decoding.
- NoOpEncodedSeeker() - Constructor for class org.apache.hadoop.hbase.io.hfile.NoOpIndexBlockEncoder.NoOpEncodedSeeker
- org.apache.hadoop.hbase.io.hfile.NoOpIndexBlockEncoder - Class in org.apache.hadoop.hbase.io.hfile
-
Does not perform any kind of encoding/decoding.
- org.apache.hadoop.hbase.io.hfile.NoOpIndexBlockEncoder.NoOpEncodedSeeker - Class in org.apache.hadoop.hbase.io.hfile
- org.apache.hadoop.hbase.client.NoopPartialResultCoprocessorCallback<S,
R> - Class in org.apache.hadoop.hbase.client - NoopPartialResultCoprocessorCallback(AsyncTable.CoprocessorCallback<R>) - Constructor for class org.apache.hadoop.hbase.client.NoopPartialResultCoprocessorCallback
- org.apache.hadoop.hbase.quotas.NoOpRegionSizeStore - Class in org.apache.hadoop.hbase.quotas
-
A
RegionSizeStore
implementation that stores nothing. - org.apache.hadoop.hbase.regionserver.NoRegionSplitRestriction - Class in org.apache.hadoop.hbase.regionserver
-
A
RegionSplitRestriction
implementation that does nothing. - NoRegionSplitRestriction() - Constructor for class org.apache.hadoop.hbase.regionserver.NoRegionSplitRestriction
- normal() - Static method in class org.apache.hadoop.hbase.hbtop.terminal.impl.EscapeSequences
- NORMAL - Enum constant in enum class org.apache.hadoop.hbase.client.CompactType
- NORMAL - Enum constant in enum class org.apache.hadoop.hbase.wal.WALTailingReader.State
-
This means we read an Entry without any error
- NORMAL_QOS - Static variable in class org.apache.hadoop.hbase.HConstants
- NORMALIZATION_ENABLED - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
Used by shell/rest interface to access this metadata attribute which denotes if the table should be treated by region normalizer.
- normalize() - Method in interface org.apache.hadoop.hbase.client.Admin
-
Invoke region normalizer.
- normalize() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Invoke region normalizer.
- normalize(NormalizeTableFilterParams) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Invoke region normalizer.
- normalize(NormalizeTableFilterParams) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Invoke region normalizer.
- normalize(RpcController, MasterProtos.NormalizeRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- normalizePriority(int) - Method in class org.apache.hadoop.hbase.ipc.AnnotationReadingPriorityFunction
- normalizePriority(int) - Method in class org.apache.hadoop.hbase.master.MasterAnnotationReadingPriorityFunction
- NORMALIZER_TARGET_REGION_COUNT - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
- NORMALIZER_TARGET_REGION_SIZE - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
Deprecated.
- NORMALIZER_TARGET_REGION_SIZE_MB - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
- normalizeRegions(NormalizeTableFilterParams, boolean) - Method in class org.apache.hadoop.hbase.master.HMaster
- normalizeRegions(NormalizeTableFilterParams, boolean) - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Perform normalization of cluster.
- normalizerSwitch(boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Turn region normalizer on or off.
- normalizerSwitch(boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Set region normalizer on/off.
- org.apache.hadoop.hbase.client.NormalizeTableFilterParams - Class in org.apache.hadoop.hbase.client
-
A collection of criteria used for table selection.
- org.apache.hadoop.hbase.client.NormalizeTableFilterParams.Builder - Class in org.apache.hadoop.hbase.client
-
Used to instantiate an instance of
NormalizeTableFilterParams
. - org.apache.hadoop.hbase.regionserver.querymatcher.NormalUserScanQueryMatcher - Class in org.apache.hadoop.hbase.regionserver.querymatcher
-
Query matcher for normal user scan.
- NormalUserScanQueryMatcher(Scan, ScanInfo, ColumnTracker, boolean, DeleteTracker, long, long) - Constructor for class org.apache.hadoop.hbase.regionserver.querymatcher.NormalUserScanQueryMatcher
- org.apache.hadoop.hbase.client.NoServerForRegionException - Exception in org.apache.hadoop.hbase.client
-
Thrown when no region server can be found for a region
- NoServerForRegionException() - Constructor for exception org.apache.hadoop.hbase.client.NoServerForRegionException
-
default constructor
- NoServerForRegionException(String) - Constructor for exception org.apache.hadoop.hbase.client.NoServerForRegionException
-
Constructor
- org.apache.hadoop.hbase.regionserver.NoSuchColumnFamilyException - Exception in org.apache.hadoop.hbase.regionserver
-
Thrown if request for nonexistent column family.
- NoSuchColumnFamilyException() - Constructor for exception org.apache.hadoop.hbase.regionserver.NoSuchColumnFamilyException
-
default constructor
- NoSuchColumnFamilyException(String) - Constructor for exception org.apache.hadoop.hbase.regionserver.NoSuchColumnFamilyException
- org.apache.hadoop.hbase.master.NoSuchProcedureException - Exception in org.apache.hadoop.hbase.master
- NoSuchProcedureException() - Constructor for exception org.apache.hadoop.hbase.master.NoSuchProcedureException
- NoSuchProcedureException(String) - Constructor for exception org.apache.hadoop.hbase.master.NoSuchProcedureException
- NOT_CALLED - Enum constant in enum class org.apache.hadoop.hbase.filter.FilterWrapper.FilterRowRetCode
- NOT_DELETED - Enum constant in enum class org.apache.hadoop.hbase.regionserver.querymatcher.DeleteTracker.DeleteResult
- NOT_DEPLOYED - Enum constant in enum class org.apache.hadoop.hbase.util.HbckErrorReporter.ERROR_CODE
-
Deprecated.
- NOT_EQUAL - Enum constant in enum class org.apache.hadoop.hbase.CompareOperator
-
not equal
- NOT_EQUAL_TO_ARRAY - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
NOT_EQUAL_TO Array
- NOT_EQUAL_TO_BUFFER - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
- NOT_IMPLEMENTED - Static variable in class org.apache.hadoop.hbase.HConstants
- NOT_IN_DICTIONARY - Static variable in interface org.apache.hadoop.hbase.io.util.Dictionary
- NOT_IN_HDFS - Enum constant in enum class org.apache.hadoop.hbase.util.HbckErrorReporter.ERROR_CODE
-
Deprecated.
- NOT_IN_HDFS_OR_DEPLOYED - Enum constant in enum class org.apache.hadoop.hbase.util.HbckErrorReporter.ERROR_CODE
-
Deprecated.
- NOT_IN_META - Enum constant in enum class org.apache.hadoop.hbase.util.HbckErrorReporter.ERROR_CODE
-
Deprecated.
- NOT_IN_META_HDFS - Enum constant in enum class org.apache.hadoop.hbase.util.HbckErrorReporter.ERROR_CODE
-
Deprecated.
- NOT_IN_META_OR_DEPLOYED - Enum constant in enum class org.apache.hadoop.hbase.util.HbckErrorReporter.ERROR_CODE
-
Deprecated.
- NOT_RUN - Enum constant in enum class org.apache.hadoop.hbase.HConstants.OperationStatusCode
- NOT_RUN - Static variable in class org.apache.hadoop.hbase.regionserver.OperationStatus
-
Singleton for operations not yet run.
- org.apache.hadoop.hbase.regionserver.NoTagByteBufferChunkKeyValue - Class in org.apache.hadoop.hbase.regionserver
-
ByteBuffer based cell which has the chunkid at the 0th offset and with no tags
- NoTagByteBufferChunkKeyValue(ByteBuffer, int, int) - Constructor for class org.apache.hadoop.hbase.regionserver.NoTagByteBufferChunkKeyValue
- NoTagByteBufferChunkKeyValue(ByteBuffer, int, int, long) - Constructor for class org.apache.hadoop.hbase.regionserver.NoTagByteBufferChunkKeyValue
- org.apache.hadoop.hbase.NoTagsByteBufferKeyValue - Class in org.apache.hadoop.hbase
-
An extension of the ByteBufferKeyValue where the tags length is always 0
- NoTagsByteBufferKeyValue(ByteBuffer, int, int) - Constructor for class org.apache.hadoop.hbase.NoTagsByteBufferKeyValue
- NoTagsByteBufferKeyValue(ByteBuffer, int, int, long) - Constructor for class org.apache.hadoop.hbase.NoTagsByteBufferKeyValue
- org.apache.hadoop.hbase.NoTagsKeyValue - Class in org.apache.hadoop.hbase
-
An extension of the KeyValue where the tags length is always 0
- NoTagsKeyValue(byte[], int, int) - Constructor for class org.apache.hadoop.hbase.NoTagsKeyValue
- org.apache.hadoop.hbase.NotAllMetaRegionsOnlineException - Exception in org.apache.hadoop.hbase
-
Thrown when an operation requires the root and all meta regions to be online
- NotAllMetaRegionsOnlineException() - Constructor for exception org.apache.hadoop.hbase.NotAllMetaRegionsOnlineException
-
default constructor
- NotAllMetaRegionsOnlineException(String) - Constructor for exception org.apache.hadoop.hbase.NotAllMetaRegionsOnlineException
- notDoubleEquals(Object) - Method in class org.apache.hadoop.hbase.hbtop.RecordFilter.FilterBuilder
- notDoubleEquals(FieldValue) - Method in class org.apache.hadoop.hbase.hbtop.RecordFilter.FilterBuilder
- notEqual(Object) - Method in class org.apache.hadoop.hbase.hbtop.RecordFilter.FilterBuilder
- notEqual(FieldValue) - Method in class org.apache.hadoop.hbase.hbtop.RecordFilter.FilterBuilder
- notExecuted(String) - Method in interface org.apache.hadoop.hbase.regionserver.FlushLifeCycleTracker
-
Called if the flush request fails for some reason.
- notGreater(Object) - Method in class org.apache.hadoop.hbase.hbtop.RecordFilter.FilterBuilder
- notGreater(FieldValue) - Method in class org.apache.hadoop.hbase.hbtop.RecordFilter.FilterBuilder
- notGreaterOrEqual(Object) - Method in class org.apache.hadoop.hbase.hbtop.RecordFilter.FilterBuilder
- notGreaterOrEqual(FieldValue) - Method in class org.apache.hadoop.hbase.hbtop.RecordFilter.FilterBuilder
- notifyAllObservers(Configuration) - Method in class org.apache.hadoop.hbase.conf.ConfigurationManager
-
The conf object has been repopulated from disk, and we have to notify all the observers that are expressed interest to do that.
- notifyFileCachingCompleted(Path, int, int, long) - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCache
-
Notifies the cache implementation that the given file has been fully cached (all its blocks made into the cache).
- notifyFileCachingCompleted(Path, int, int, long) - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
- notifyOnCancel(RpcCallback<Object>) - Method in class org.apache.hadoop.hbase.client.ClientCoprocessorRpcController
- notifyOnCancel(RpcCallback<Object>) - Method in class org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
- notifyOnCancel(RpcCallback<Object>) - Method in interface org.apache.hadoop.hbase.ipc.HBaseRpcController
-
A little different from the basic RpcController: You can register multiple callbacks to an
HBaseRpcController
. The callback will not be called if the rpc call is finished without any cancellation. You can call me at client side also. - notifyOnCancel(RpcCallback<Object>) - Method in class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
- notifyOnCancel(RpcCallback<Object>) - Method in class org.apache.hadoop.hbase.ipc.ServerRpcController
- notifyOnCancel(RpcCallback<Object>, HBaseRpcController.CancellationCallback) - Method in class org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
- notifyOnCancel(RpcCallback<Object>, HBaseRpcController.CancellationCallback) - Method in interface org.apache.hadoop.hbase.ipc.HBaseRpcController
-
If not cancelled, add the callback to cancellation callback list.
- notifyOnCancel(RpcCallback<Object>, HBaseRpcController.CancellationCallback) - Method in class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
- notInViolation() - Static method in class org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot.SpaceQuotaStatus
-
Returns a singleton referring to a quota which is not in violation.
- notLess(Object) - Method in class org.apache.hadoop.hbase.hbtop.RecordFilter.FilterBuilder
- notLess(FieldValue) - Method in class org.apache.hadoop.hbase.hbtop.RecordFilter.FilterBuilder
- notLessOrEqual(Object) - Method in class org.apache.hadoop.hbase.hbtop.RecordFilter.FilterBuilder
- notLessOrEqual(FieldValue) - Method in class org.apache.hadoop.hbase.hbtop.RecordFilter.FilterBuilder
- NotSeekedException(Path) - Constructor for exception org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.NotSeekedException
- notServingRegionException() - Method in interface org.apache.hadoop.hbase.metrics.ExceptionTrackingSource
- notServingRegionException() - Method in class org.apache.hadoop.hbase.metrics.ExceptionTrackingSourceImpl
- org.apache.hadoop.hbase.NotServingRegionException - Exception in org.apache.hadoop.hbase
-
Thrown by a region server if it is sent a request for a region it is not serving.
- NotServingRegionException() - Constructor for exception org.apache.hadoop.hbase.NotServingRegionException
- NotServingRegionException(byte[]) - Constructor for exception org.apache.hadoop.hbase.NotServingRegionException
- NotServingRegionException(String) - Constructor for exception org.apache.hadoop.hbase.NotServingRegionException
- now - Variable in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher
- org.apache.hadoop.hbase.quotas.policies.NoWritesCompactionsViolationPolicyEnforcement - Class in org.apache.hadoop.hbase.quotas.policies
-
A
SpaceViolationPolicyEnforcement
implementation which disables all updates and compactions. - NoWritesCompactionsViolationPolicyEnforcement() - Constructor for class org.apache.hadoop.hbase.quotas.policies.NoWritesCompactionsViolationPolicyEnforcement
- org.apache.hadoop.hbase.quotas.policies.NoWritesViolationPolicyEnforcement - Class in org.apache.hadoop.hbase.quotas.policies
-
A
SpaceViolationPolicyEnforcement
implementation which disables all writes flowing into HBase. - NoWritesViolationPolicyEnforcement() - Constructor for class org.apache.hadoop.hbase.quotas.policies.NoWritesViolationPolicyEnforcement
- NS_QUOTA_USAGE_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterQuotaSource
- NS_QUOTA_USAGE_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterQuotaSource
- NULL - Enum constant in enum class org.apache.hadoop.hbase.util.ChecksumType
- NULL_META_REGION - Enum constant in enum class org.apache.hadoop.hbase.util.HbckErrorReporter.ERROR_CODE
-
Deprecated.
- NULL_VALUE - Static variable in class org.apache.hadoop.hbase.regionserver.HStoreFile
-
Null data
- org.apache.hadoop.hbase.filter.NullComparator - Class in org.apache.hadoop.hbase.filter
-
A binary comparator which lexicographically compares against the specified byte array using
Bytes.compareTo(byte[], byte[])
. - NullComparator() - Constructor for class org.apache.hadoop.hbase.filter.NullComparator
- nullResult - Variable in class org.apache.hadoop.hbase.util.MultiThreadedReader
- NUM_ACTIVE_BULKLOAD_HANDLER_DESC - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
- NUM_ACTIVE_BULKLOAD_HANDLER_NAME - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
- NUM_ACTIVE_GENERAL_HANDLER_DESC - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
- NUM_ACTIVE_GENERAL_HANDLER_NAME - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
- NUM_ACTIVE_HANDLER_DESC - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
- NUM_ACTIVE_HANDLER_NAME - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
- NUM_ACTIVE_PRIORITY_HANDLER_DESC - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
- NUM_ACTIVE_PRIORITY_HANDLER_NAME - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
- NUM_ACTIVE_READ_HANDLER_DESC - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
- NUM_ACTIVE_READ_HANDLER_NAME - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
- NUM_ACTIVE_REPLICATION_HANDLER_DESC - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
- NUM_ACTIVE_REPLICATION_HANDLER_NAME - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
- NUM_ACTIVE_SCAN_HANDLER_DESC - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
- NUM_ACTIVE_SCAN_HANDLER_NAME - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
- NUM_ACTIVE_WRITE_HANDLER_DESC - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
- NUM_ACTIVE_WRITE_HANDLER_NAME - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
- NUM_BYTES_COMPACTED_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
- NUM_BYTES_COMPACTED_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
- NUM_CELLS - Enum constant in enum class org.apache.hadoop.hbase.ScanPerformanceEvaluation.ScanCounter
- NUM_DEAD_REGION_SERVERS_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
- NUM_DRAINING_REGION_SERVERS_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
- NUM_FAILED_PUTS - Static variable in interface org.apache.hadoop.hbase.namequeues.MetricsWALEventTrackerSource
- NUM_FAILED_PUTS_DESC - Static variable in interface org.apache.hadoop.hbase.namequeues.MetricsWALEventTrackerSource
- NUM_FILES_COMPACTED_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
- NUM_FILES_COMPACTED_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
- NUM_GENERAL_CALLS_DROPPED_DESC - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
- NUM_GENERAL_CALLS_DROPPED_NAME - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
- NUM_LIFO_MODE_SWITCHES_DESC - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
- NUM_LIFO_MODE_SWITCHES_NAME - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
- NUM_MAPPERS_PER_REGION - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
Set the number of Mappers for each region, all regions have same number of Mappers
- NUM_MASTER_WALS_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterProcSource
- NUM_MASTER_WALS_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterProcSource
- NUM_NS_QUOTA_VIOLATIONS_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterQuotaSource
- NUM_NS_QUOTA_VIOLATIONS_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterQuotaSource
- NUM_OPEN_CONNECTIONS_DESC - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
- NUM_OPEN_CONNECTIONS_NAME - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
- NUM_OPS_METRIC_NAME - Static variable in interface org.apache.hadoop.metrics2.MetricHistogram
- NUM_RECORDS_FAILED_PUTS - Static variable in interface org.apache.hadoop.hbase.namequeues.MetricsWALEventTrackerSource
- NUM_RECORDS_FAILED_PUTS_DESC - Static variable in interface org.apache.hadoop.hbase.namequeues.MetricsWALEventTrackerSource
- NUM_REFERENCE_FILES - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- NUM_REFERENCE_FILES_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- NUM_REGION_SERVERS_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
- NUM_REGION_SIZE_REPORT_NAME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerQuotaSource
- NUM_REGION_SIZE_REPORTS_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterQuotaSource
- NUM_REGION_SIZE_REPORTS_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterQuotaSource
- NUM_ROWS - Enum constant in enum class org.apache.hadoop.hbase.ScanPerformanceEvaluation.ScanCounter
- NUM_SPACE_QUOTAS_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterQuotaSource
- NUM_SPACE_QUOTAS_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterQuotaSource
- NUM_SPACE_SNAPSHOTS_RECEIVED_NAME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerQuotaSource
- NUM_SPLITS_PER_REGION - Static variable in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl
-
For MapReduce jobs running multiple mappers per region, determines number of splits to generate per region.
- NUM_STORE_FILES - Enum constant in enum class org.apache.hadoop.hbase.hbtop.field.Field
- NUM_TABLES - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsTableAggregateSource
- NUM_TABLES - Static variable in class org.apache.hadoop.hbase.util.LoadTestTool
- NUM_TABLES_IN_VIOLATION_NAME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerQuotaSource
- NUM_TABLES_QUOTA_VIOLATIONS_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterQuotaSource
- NUM_TABLES_QUOTA_VIOLATIONS_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterQuotaSource
- NUM_USERS - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsUserAggregateSource
- numAlwaysStandByMasters(int) - Method in class org.apache.hadoop.hbase.StartMiniClusterOption.Builder
-
Deprecated.
- numAlwaysStandByMasters(int) - Method in class org.apache.hadoop.hbase.testing.TestingHBaseClusterOption.Builder
- NUMBER_OF_DEAD_REGION_SERVERS_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
- NUMBER_OF_DRAINING_REGION_SERVERS_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
- NUMBER_OF_MUTATIONS_WITHOUT_WAL - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- NUMBER_OF_MUTATIONS_WITHOUT_WAL_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- NUMBER_OF_REGION_SERVERS_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
- NUMBER_OF_TABLES_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsTableAggregateSource
- NUMBER_OF_THREADS - Static variable in class org.apache.hadoop.hbase.mapreduce.MultithreadedTableMapper
- NUMBER_OF_USERS_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsUserAggregateSource
- numberOfCompleteRows() - Method in class org.apache.hadoop.hbase.client.BatchScanResultCache
- numbOfReplyOverThreshold - Variable in class org.apache.hadoop.hbase.PerformanceEvaluation.RunResult
- numCallQueues - Variable in class org.apache.hadoop.hbase.ipc.RpcExecutor
- numChunks - Variable in class org.apache.hadoop.hbase.io.hfile.CompoundBloomFilterBase
-
At read time, the total number of chunks.
- numCols - Variable in class org.apache.hadoop.hbase.util.MultiThreadedAction
- numDataNodes(int) - Method in class org.apache.hadoop.hbase.StartMiniClusterOption.Builder
-
Deprecated.
- numDataNodes(int) - Method in class org.apache.hadoop.hbase.testing.TestingHBaseClusterOption.Builder
- numEntries - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
- numEqualPrefixBytes(ByteRange, ByteRange, int) - Static method in class org.apache.hadoop.hbase.util.ByteRangeUtils
- numFamilies() - Method in class org.apache.hadoop.hbase.client.Get
-
Method for retrieving the number of families to get from
- numFamilies() - Method in class org.apache.hadoop.hbase.client.ImmutableScan
- numFamilies() - Method in class org.apache.hadoop.hbase.client.Increment
-
Method for retrieving the number of families to increment from
- numFamilies() - Method in class org.apache.hadoop.hbase.client.Mutation
-
Returns the number of different families
- numFamilies() - Method in class org.apache.hadoop.hbase.client.Scan
-
Returns the number of families in familyMap
- numKeys - Variable in class org.apache.hadoop.hbase.util.MultiThreadedAction
- numKeysVerified - Variable in class org.apache.hadoop.hbase.util.MultiThreadedReader
- numMasters(int) - Method in class org.apache.hadoop.hbase.StartMiniClusterOption.Builder
-
Deprecated.
- numMasters(int) - Method in class org.apache.hadoop.hbase.testing.TestingHBaseClusterOption.Builder
- numNonNullElements() - Method in class org.apache.hadoop.hbase.RegionLocations
-
Returns the size of not-null locations
- numOfReplyFromReplica - Variable in class org.apache.hadoop.hbase.PerformanceEvaluation.RunResult
- numReadErrors - Variable in class org.apache.hadoop.hbase.util.MultiThreadedReader
- numReadFailures - Variable in class org.apache.hadoop.hbase.util.MultiThreadedReader
- NumReadRequestsExceeded - Enum constant in enum class org.apache.hadoop.hbase.quotas.RpcThrottlingException.Type
- numRegionServers(int) - Method in class org.apache.hadoop.hbase.StartMiniClusterOption.Builder
-
Deprecated.
- numRegionServers(int) - Method in class org.apache.hadoop.hbase.testing.TestingHBaseClusterOption.Builder
- NumRequestsExceeded - Enum constant in enum class org.apache.hadoop.hbase.quotas.RpcThrottlingException.Type
- numThreads - Variable in class org.apache.hadoop.hbase.util.MultiThreadedAction
- numThreads - Variable in class org.apache.hadoop.hbase.wal.BoundedRecoveredHFilesOutputSink
- numThreadsWorking - Variable in class org.apache.hadoop.hbase.util.MultiThreadedAction
- numUpdaterThreads - Variable in class org.apache.hadoop.hbase.util.LoadTestTool
- NumWriteRequestsExceeded - Enum constant in enum class org.apache.hadoop.hbase.quotas.RpcThrottlingException.Type
- numWriterThreads - Variable in class org.apache.hadoop.hbase.util.LoadTestTool
- numZkServers(int) - Method in class org.apache.hadoop.hbase.StartMiniClusterOption.Builder
-
Deprecated.
- numZkServers(int) - Method in class org.apache.hadoop.hbase.testing.TestingHBaseClusterOption.Builder
O
- O - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
ASCII code for 'O'
- OBJECT - Static variable in class org.apache.hadoop.hbase.util.ClassSize
-
Object overhead is minimum 2 * reference size (8 bytes on 64-bit)
- org.apache.hadoop.hbase.util.ObjectIntPair<T> - Class in org.apache.hadoop.hbase.util
-
A generic class for pair of an Object and and a primitive int value.
- ObjectIntPair() - Constructor for class org.apache.hadoop.hbase.util.ObjectIntPair
- ObjectIntPair(T, int) - Constructor for class org.apache.hadoop.hbase.util.ObjectIntPair
- org.apache.hadoop.hbase.util.ObjectPool<K,
V> - Class in org.apache.hadoop.hbase.util -
A thread-safe shared object pool in which object creation is expected to be lightweight, and the objects may be excessively created and discarded.
- ObjectPool(ObjectPool.ObjectFactory<K, V>) - Constructor for class org.apache.hadoop.hbase.util.ObjectPool
-
Creates a new pool with the default initial capacity (16) and the default concurrency level (16).
- ObjectPool(ObjectPool.ObjectFactory<K, V>, int) - Constructor for class org.apache.hadoop.hbase.util.ObjectPool
-
Creates a new pool with the given initial capacity and the default concurrency level (16).
- ObjectPool(ObjectPool.ObjectFactory<K, V>, int, int) - Constructor for class org.apache.hadoop.hbase.util.ObjectPool
-
Creates a new pool with the given initial capacity and the given concurrency level.
- org.apache.hadoop.hbase.util.ObjectPool.ObjectFactory<K,
V> - Interface in org.apache.hadoop.hbase.util -
An
ObjectFactory
object is used to create new shared objects on demand. - org.apache.hadoop.hbase.coprocessor.ObserverContext<E extends org.apache.hadoop.hbase.CoprocessorEnvironment> - Interface in org.apache.hadoop.hbase.coprocessor
-
Carries the execution state for a given invocation of an Observer coprocessor (
RegionObserver
,MasterObserver
, orWALObserver
) method. - org.apache.hadoop.hbase.coprocessor.ObserverContextImpl<E extends org.apache.hadoop.hbase.CoprocessorEnvironment> - Class in org.apache.hadoop.hbase.coprocessor
-
This is the only implementation of
ObserverContext
, which serves as the interface for third-party Coprocessor developers. - ObserverContextImpl(User) - Constructor for class org.apache.hadoop.hbase.coprocessor.ObserverContextImpl
- ObserverContextImpl(User, boolean) - Constructor for class org.apache.hadoop.hbase.coprocessor.ObserverContextImpl
- ObserverOperationWithoutResult(CoprocessorHost.ObserverGetter<C, O>) - Constructor for class org.apache.hadoop.hbase.coprocessor.CoprocessorHost.ObserverOperationWithoutResult
- ObserverOperationWithoutResult(CoprocessorHost.ObserverGetter<C, O>, User) - Constructor for class org.apache.hadoop.hbase.coprocessor.CoprocessorHost.ObserverOperationWithoutResult
- ObserverOperationWithoutResult(CoprocessorHost.ObserverGetter<C, O>, User, boolean) - Constructor for class org.apache.hadoop.hbase.coprocessor.CoprocessorHost.ObserverOperationWithoutResult
- ObserverOperationWithResult(CoprocessorHost.ObserverGetter<C, O>, R) - Constructor for class org.apache.hadoop.hbase.coprocessor.CoprocessorHost.ObserverOperationWithResult
- ObserverOperationWithResult(CoprocessorHost.ObserverGetter<C, O>, R, boolean) - Constructor for class org.apache.hadoop.hbase.coprocessor.CoprocessorHost.ObserverOperationWithResult
- ObserverOperationWithResult(CoprocessorHost.ObserverGetter<C, O>, R, User) - Constructor for class org.apache.hadoop.hbase.coprocessor.CoprocessorHost.ObserverOperationWithResult
- of(byte[]) - Static method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
- of(String) - Static method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
- of(String) - Static method in class org.apache.hadoop.hbase.client.CoprocessorDescriptorBuilder
- of(List<? extends Mutation>) - Static method in class org.apache.hadoop.hbase.client.RowMutations
-
Create a
RowMutations
with the specified mutations. - of(ServerName) - Static method in class org.apache.hadoop.hbase.ServerMetricsBuilder
- of(ServerName, int, String) - Static method in class org.apache.hadoop.hbase.ServerMetricsBuilder
- ofEntries(Stream<Record.Entry>) - Static method in class org.apache.hadoop.hbase.hbtop.Record
- ofEntries(Record.Entry...) - Static method in class org.apache.hadoop.hbase.hbtop.Record
- offer(E) - Method in class org.apache.hadoop.hbase.util.BoundedPriorityBlockingQueue
- offer(E, long, TimeUnit) - Method in class org.apache.hadoop.hbase.util.BoundedPriorityBlockingQueue
- offer(Runnable) - Method in class org.apache.hadoop.hbase.thrift.CallQueue
- offer(Runnable, long, TimeUnit) - Method in class org.apache.hadoop.hbase.thrift.CallQueue
- offer(CallRunner) - Method in class org.apache.hadoop.hbase.ipc.AdaptiveLifoCoDelCallQueue
- offer(CallRunner, long, TimeUnit) - Method in class org.apache.hadoop.hbase.ipc.AdaptiveLifoCoDelCallQueue
- offer(SyncFuture) - Method in class org.apache.hadoop.hbase.regionserver.wal.SyncFutureCache
-
Offers the sync future back to the cache for reuse.
- offer(T) - Method in class org.apache.hadoop.hbase.util.StealJobQueue
- OFFHEAP_MEMSTORE_SIZE_KEY - Static variable in class org.apache.hadoop.hbase.io.util.MemorySizeUtil
- org.apache.hadoop.hbase.regionserver.OffheapChunk - Class in org.apache.hadoop.hbase.regionserver
-
An off heap chunk implementation.
- offHeapSizeChange(Cell, boolean) - Method in class org.apache.hadoop.hbase.regionserver.Segment
- offline(byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Offline specified region from master's in-memory state.
- offline(byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Offline specified region from master's in-memory state.
- OFFLINE - Enum constant in enum class org.apache.hadoop.hbase.master.RegionState.State
- OFFLINE_REGION_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
- OFFLINE_REGION_COUNT_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
- offlineHdfsIntegrityRepair() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.This repair method analyzes hbase data in hdfs and repairs it to satisfy the table integrity rules.
- offlineRegion(RpcController, MasterProtos.OfflineRegionRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
Offline specified region from master's in-memory state.
- offPeakHours - Variable in class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareThroughputController
- offset - Variable in class org.apache.hadoop.hbase.ByteBufferKeyValue
- offset - Variable in class org.apache.hadoop.hbase.KeyValue
- offset - Variable in class org.apache.hadoop.hbase.util.AbstractByteRange
-
The index of the first byte in this range.
- OLD_META_STR - Static variable in class org.apache.hadoop.hbase.TableName
- OLD_META_TABLE_NAME - Static variable in class org.apache.hadoop.hbase.TableName
-
TableName for old .META.
- OLD_ROOT_STR - Static variable in class org.apache.hadoop.hbase.TableName
- OLD_ROOT_TABLE_NAME - Static variable in class org.apache.hadoop.hbase.TableName
-
TableName for old -ROOT- table.
- OLD_SNAPSHOT_DIR_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
- OLD_WAL_DIR_SIZE_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
- OLD_WAL_DIR_SIZE_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
- OLDEST_TIMESTAMP - Static variable in class org.apache.hadoop.hbase.PrivateConstants
-
Timestamp to use when we want to refer to the oldest cell.
- oldestUnexpiredTS - Variable in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher
-
The oldest timestamp we are interested in, based on TTL
- org.apache.hadoop.hbase.master.OldWALsDirSizeChore - Class in org.apache.hadoop.hbase.master
-
This chore is used to update the 'oldWALsDirSize' variable in
MasterWalManager
through theMasterWalManager.updateOldWALsDirSize()
method. - OldWALsDirSizeChore(MasterServices) - Constructor for class org.apache.hadoop.hbase.master.OldWALsDirSizeChore
- onComplete() - Method in interface org.apache.hadoop.hbase.client.AsyncTable.CoprocessorCallback
-
Indicate that all responses of the regions have been notified by calling
AsyncTable.CoprocessorCallback.onRegionComplete(RegionInfo, Object)
orAsyncTable.CoprocessorCallback.onRegionError(RegionInfo, Throwable)
. - onComplete() - Method in class org.apache.hadoop.hbase.client.NoopPartialResultCoprocessorCallback
- onComplete() - Method in interface org.apache.hadoop.hbase.client.ScanResultConsumerBase
-
Indicate that the scan operation is completed normally.
- onConfigurationChange(Configuration) - Method in interface org.apache.hadoop.hbase.conf.ConfigurationObserver
-
This method would be called by the
ConfigurationManager
object when theConfiguration
object is reloaded from disk. - onConfigurationChange(Configuration) - Method in class org.apache.hadoop.hbase.HBaseRpcServicesBase
- onConfigurationChange(Configuration) - Method in class org.apache.hadoop.hbase.io.asyncfs.monitor.ExcludeDatanodeManager
- onConfigurationChange(Configuration) - Method in class org.apache.hadoop.hbase.io.asyncfs.monitor.StreamSlowMonitor
- onConfigurationChange(Configuration) - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
- onConfigurationChange(Configuration) - Method in class org.apache.hadoop.hbase.ipc.BalancedQueueRpcExecutor
- onConfigurationChange(Configuration) - Method in class org.apache.hadoop.hbase.ipc.NettyRpcServer
- onConfigurationChange(Configuration) - Method in class org.apache.hadoop.hbase.ipc.RpcExecutor
- onConfigurationChange(Configuration) - Method in class org.apache.hadoop.hbase.ipc.RpcServer
- onConfigurationChange(Configuration) - Method in class org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
- onConfigurationChange(Configuration) - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
-
Resize call queues;
- onConfigurationChange(Configuration) - Method in class org.apache.hadoop.hbase.master.HMaster
- onConfigurationChange(Configuration) - Method in interface org.apache.hadoop.hbase.master.LoadBalancer
-
Notification that config has changed
- onConfigurationChange(Configuration) - Method in class org.apache.hadoop.hbase.master.RegionsRecoveryConfigManager
- onConfigurationChange(Configuration) - Method in class org.apache.hadoop.hbase.master.ServerManager
-
Implementation of the ConfigurationObserver interface.
- onConfigurationChange(Configuration) - Method in class org.apache.hadoop.hbase.regionserver.CompactSplit
-
This method would be called by the
ConfigurationManager
object when theConfiguration
object is reloaded from disk. - onConfigurationChange(Configuration) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
This method would be called by the
ConfigurationManager
object when theConfiguration
object is reloaded from disk. - onConfigurationChange(Configuration) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
- onConfigurationChange(Configuration) - Method in class org.apache.hadoop.hbase.regionserver.HStore
- onConfigurationChange(Configuration) - Method in class org.apache.hadoop.hbase.regionserver.MemStoreFlusher
- onConfigurationChange(Configuration) - Method in class org.apache.hadoop.hbase.regionserver.PrefetchExecutorNotifier
-
This method would be called by the
ConfigurationManager
object when theConfiguration
object is reloaded from disk. - onConfigurationChange(Configuration) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
- onConfigurationChange(Configuration) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerImpl
- onConfigurationChange(Configuration) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeers
- onConfigurationChange(Configuration) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupBasedLoadBalancer
- ONE - Enum constant in enum class org.apache.hadoop.hbase.thrift.ThriftMetrics.ThriftServerType
- oneRound - Variable in class org.apache.hadoop.hbase.util.WindowMovingAverage
- onError(Throwable) - Method in interface org.apache.hadoop.hbase.client.AsyncTable.CoprocessorCallback
-
Indicate that we got an error which does not belong to any regions.
- onError(Throwable) - Method in class org.apache.hadoop.hbase.client.NoopPartialResultCoprocessorCallback
- onError(Throwable) - Method in interface org.apache.hadoop.hbase.client.ScanResultConsumerBase
-
Indicate that we hit an unrecoverable error and the scan operation is terminated.
- onError(Throwable, Supplier<String>, Consumer<Throwable>) - Method in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCaller
- onException(RetriesExhaustedWithDetailsException, BufferedMutator) - Method in interface org.apache.hadoop.hbase.client.BufferedMutator.ExceptionListener
- org.apache.hadoop.hbase.regionserver.OnheapChunk - Class in org.apache.hadoop.hbase.regionserver
-
An on heap chunk implementation.
- onHeapMemoryTune(long, long) - Method in interface org.apache.hadoop.hbase.regionserver.HeapMemoryManager.HeapMemoryTuneObserver
-
This method would be called by HeapMemoryManger when a heap memory tune action took place.
- onHeartbeat(AdvancedScanResultConsumer.ScanController) - Method in interface org.apache.hadoop.hbase.client.AdvancedScanResultConsumer
-
Indicate that there is a heartbeat message but we have not cumulated enough cells to call
AdvancedScanResultConsumer.onNext(Result[], ScanController)
. - ONLINE_REGION_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
- ONLINE_REGION_COUNT_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
- onlineConsistencyRepair() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.This repair method requires the cluster to be online since it contacts region servers and the masters.
- onlineHbck() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.Contacts the master and prints out cluster-wide information
- OnlineLogRecord - Class in org.apache.hadoop.hbase.client
-
Slow/Large Log payload for hbase-client, to be used by Admin API get_slow_responses and get_large_responses
- org.apache.hadoop.hbase.client.OnlineLogRecord.OnlineLogRecordBuilder - Class in org.apache.hadoop.hbase.client
- OnlineLogRecordBuilder() - Constructor for class org.apache.hadoop.hbase.client.OnlineLogRecord.OnlineLogRecordBuilder
- org.apache.hadoop.hbase.regionserver.OnlineRegions - Interface in org.apache.hadoop.hbase.regionserver
-
Provides read-only access to the Regions presently online on the current RegionServer
- onNext(Result) - Method in interface org.apache.hadoop.hbase.client.ScanResultConsumer
-
Return
false
if you want to terminate the scan process. - onNext(Result[], AdvancedScanResultConsumer.ScanController) - Method in interface org.apache.hadoop.hbase.client.AdvancedScanResultConsumer
-
Indicate that we have receive some data.
- onRegionComplete(RegionInfo, R) - Method in interface org.apache.hadoop.hbase.client.AsyncTable.CoprocessorCallback
-
Indicate that the respose of a region is available
- onRegionComplete(RegionInfo, R) - Method in class org.apache.hadoop.hbase.client.NoopPartialResultCoprocessorCallback
- onRegionError(RegionInfo, Throwable) - Method in interface org.apache.hadoop.hbase.client.AsyncTable.CoprocessorCallback
-
Indicate that the error for a region is available
- onRegionError(RegionInfo, Throwable) - Method in class org.apache.hadoop.hbase.client.NoopPartialResultCoprocessorCallback
- onRegionMerged(RegionInfo) - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
- onRegionMerged(RegionInfo) - Method in interface org.apache.hadoop.hbase.RegionStateListener
-
Process region merge event.
- onRegionSplit(RegionInfo) - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
- onRegionSplit(RegionInfo) - Method in interface org.apache.hadoop.hbase.RegionStateListener
-
Process region split event.
- onRegionSplitReverted(RegionInfo) - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
- onRegionSplitReverted(RegionInfo) - Method in interface org.apache.hadoop.hbase.RegionStateListener
-
Process region split reverted event.
- onScanMetricsCreated(ScanMetrics) - Method in interface org.apache.hadoop.hbase.client.ScanResultConsumerBase
-
If
scan.isScanMetricsEnabled()
returns true, then this method will be called prior to all other methods in this interface to give you theScanMetrics
instance for this scan operation. - onWriterReplaced(WALProvider.AsyncWriter) - Method in class org.apache.hadoop.hbase.regionserver.wal.AsyncFSWAL
- onWriterReplaced(WALProvider.Writer) - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
- onWriterReplaced(W) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
- OOM - Static variable in class org.apache.hadoop.hbase.regionserver.Chunk
- org.apache.hadoop.hbase.util.OOMEChecker - Class in org.apache.hadoop.hbase.util
- op - Variable in class org.apache.hadoop.hbase.filter.CompareFilter
- op - Variable in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
- open() - Method in class org.apache.hadoop.hbase.mob.CachedMobFile
-
Opens the mob file if it's not opened yet and increases the reference.
- open() - Method in class org.apache.hadoop.hbase.mob.MobFile
-
Opens the underlying reader.
- open() - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractProtobufWALReader
- open(InputStream) - Method in class org.apache.hadoop.hbase.mapreduce.CellSerialization.CellDeserializer
- open(InputStream) - Method in class org.apache.hadoop.hbase.mapreduce.ExtendedCellSerialization.ExtendedCellDeserializer
- open(OutputStream) - Method in class org.apache.hadoop.hbase.mapreduce.CellSerialization.CellSerializer
- open(OutputStream) - Method in class org.apache.hadoop.hbase.mapreduce.ExtendedCellSerialization.ExtendedCellSerializer
- open(PrintWriter) - Method in class org.apache.hadoop.hbase.util.JSONBean
-
Notice that, closing the return
JSONBean.Writer
will not close thewriter
passed in, you still need to close thewriter
by yourself. - open(Configuration) - Static method in class org.apache.hadoop.hbase.quotas.QuotaRetriever
-
Deprecated.Since 3.0.0, will be removed in 4.0.0. Use
QuotaRetriever(Configuration, Scan)
instead. - open(Configuration, FileSystem, Path, SnapshotProtos.SnapshotDescription) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotManifest
-
Return a SnapshotManifest instance with the information already loaded in-memory.
- open(Configuration, QuotaFilter) - Static method in class org.apache.hadoop.hbase.quotas.QuotaRetriever
-
Deprecated.Since 3.0.0, will be removed in 4.0.0. Use
QuotaRetriever(Configuration, Scan)
instead. - open(FileSystem) - Method in class org.apache.hadoop.hbase.io.FileLink
-
Open the FileLink for read.
- open(FileSystem, int) - Method in class org.apache.hadoop.hbase.io.FileLink
-
Open the FileLink for read.
- OPEN - Enum constant in enum class org.apache.hadoop.hbase.master.RegionState.State
- OPEN_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
-
The key value used for range boundary, indicating that the boundary is open (i.e.
- OPEN_METRIC_PREFIX - Static variable in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
- openFile(FileSystem, Path, CacheConfig, StoreContext) - Method in class org.apache.hadoop.hbase.mob.MobFileCache
-
Opens a mob file.
- openHRegion(Configuration, FileSystem, Path, RegionInfo, TableDescriptor, WAL) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Open a Region.
- openHRegion(Configuration, FileSystem, Path, RegionInfo, TableDescriptor, WAL, RegionServerServices, CancelableProgressable) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Open a Region.
- openHRegion(Path, RegionInfo, TableDescriptor, WAL, Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Open a Region.
- openHRegion(Path, RegionInfo, TableDescriptor, WAL, Configuration, RegionServerServices, CancelableProgressable) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Open a Region.
- openHRegion(RegionInfo, TableDescriptor, WAL, Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Open a Region.
- openHRegion(RegionInfo, TableDescriptor, WAL, Configuration, RegionServerServices, CancelableProgressable) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Open a Region.
- openHRegion(HRegion, CancelableProgressable) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Useful when reopening a closed region (normally for unit tests)
- openHRegion(Region, CancelableProgressable) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
- openHRegionFromTableDir(Configuration, FileSystem, Path, RegionInfo, TableDescriptor, WAL, RegionServerServices, CancelableProgressable) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Open a Region.
- OPENING - Enum constant in enum class org.apache.hadoop.hbase.master.RegionState.State
- openReadOnlyFileSystemHRegion(Configuration, FileSystem, Path, RegionInfo, TableDescriptor) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Open a Region on a read-only file-system (like hdfs snapshots)
- openRegion(AdminProtos.OpenRegionRequest) - Method in class org.apache.hadoop.hbase.client.AsyncRegionServerAdmin
- openRegion(RpcController, AdminProtos.AdminService.BlockingInterface, ServerName, RegionInfo) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
A helper to open a region using admin protocol.
- openRegion(RpcController, AdminProtos.OpenRegionRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- openRegion(RpcController, AdminProtos.OpenRegionRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
Open asynchronously a region or a set of regions on the region server.
- openRegionFromFileSystem(Configuration, FileSystem, Path, RegionInfo, boolean) - Static method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
Open Region from file-system.
- org.apache.hadoop.hbase.client.Operation - Class in org.apache.hadoop.hbase.client
-
Superclass for any type that maps to a potentially application-level query.
- Operation() - Constructor for class org.apache.hadoop.hbase.client.Operation
- OPERATION_COUNT_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
- OPERATION_TIMEOUT_MS - Static variable in class org.apache.hadoop.hbase.regionserver.regionreplication.RegionReplicationSink
- OPERATION_TIMEOUT_MS_DEFAULT - Static variable in class org.apache.hadoop.hbase.regionserver.regionreplication.RegionReplicationSink
- org.apache.hadoop.hbase.metrics.OperationMetrics - Class in org.apache.hadoop.hbase.metrics
-
Container class for commonly collected metrics for most operations.
- OperationMetrics(MetricRegistry, String) - Constructor for class org.apache.hadoop.hbase.metrics.OperationMetrics
- org.apache.hadoop.hbase.quotas.OperationQuota - Interface in org.apache.hadoop.hbase.quotas
-
Interface that allows to check the quota available for an operation.
- org.apache.hadoop.hbase.quotas.OperationQuota.OperationType - Enum Class in org.apache.hadoop.hbase.quotas
- org.apache.hadoop.hbase.regionserver.OperationStatus - Class in org.apache.hadoop.hbase.regionserver
-
This class stores the Operation status code and the exception message that occurs in case of failure of operations like put, delete, etc.
- OperationStatus(HConstants.OperationStatusCode) - Constructor for class org.apache.hadoop.hbase.regionserver.OperationStatus
- OperationStatus(HConstants.OperationStatusCode, Exception) - Constructor for class org.apache.hadoop.hbase.regionserver.OperationStatus
- OperationStatus(HConstants.OperationStatusCode, String) - Constructor for class org.apache.hadoop.hbase.regionserver.OperationStatus
- OperationStatus(HConstants.OperationStatusCode, Result) - Constructor for class org.apache.hadoop.hbase.regionserver.OperationStatus
- operationTimeout(int) - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
- operationTimeoutNs - Variable in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCaller
- org.apache.hadoop.hbase.client.OperationWithAttributes - Class in org.apache.hadoop.hbase.client
- OperationWithAttributes() - Constructor for class org.apache.hadoop.hbase.client.OperationWithAttributes
-
empty construction.
- OperationWithAttributes(OperationWithAttributes) - Constructor for class org.apache.hadoop.hbase.client.OperationWithAttributes
- opertationTimeout(int) - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
-
Deprecated.Since 2.3.0, will be removed in 4.0.0. Use
BufferedMutatorParams.operationTimeout(int)
- OPS_SAMPLE_NAME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
- OPT_BATCHUPDATE - Static variable in class org.apache.hadoop.hbase.util.LoadTestTool
- OPT_BLOOM - Static variable in class org.apache.hadoop.hbase.util.LoadTestTool
- OPT_BLOOM_PARAM - Static variable in class org.apache.hadoop.hbase.util.LoadTestTool
- OPT_COLUMN_FAMILIES - Static variable in class org.apache.hadoop.hbase.util.LoadTestTool
- OPT_COMPRESSION - Static variable in class org.apache.hadoop.hbase.util.LoadTestTool
- OPT_DATA_BLOCK_ENCODING - Static variable in class org.apache.hadoop.hbase.util.LoadTestUtil
- OPT_DATA_BLOCK_ENCODING_USAGE - Static variable in class org.apache.hadoop.hbase.util.LoadTestUtil
- OPT_DEFERRED_LOG_FLUSH - Static variable in class org.apache.hadoop.hbase.util.LoadTestTool
- OPT_DEFERRED_LOG_FLUSH_USAGE - Static variable in class org.apache.hadoop.hbase.util.LoadTestTool
- OPT_ENCRYPTION - Static variable in class org.apache.hadoop.hbase.util.LoadTestTool
- OPT_ENCRYPTION_USAGE - Static variable in class org.apache.hadoop.hbase.util.LoadTestTool
- OPT_GENERATOR - Static variable in class org.apache.hadoop.hbase.util.LoadTestTool
- OPT_GENERATOR_USAGE - Static variable in class org.apache.hadoop.hbase.util.LoadTestTool
- OPT_INIT_ONLY - Static variable in class org.apache.hadoop.hbase.util.LoadTestTool
- OPT_INMEMORY - Static variable in class org.apache.hadoop.hbase.util.LoadTestTool
- OPT_KEY_WINDOW - Static variable in class org.apache.hadoop.hbase.util.LoadTestTool
- OPT_MAX_READ_ERRORS - Static variable in class org.apache.hadoop.hbase.util.LoadTestTool
- OPT_MOB_THRESHOLD - Static variable in class org.apache.hadoop.hbase.util.LoadTestTool
- OPT_MOB_THRESHOLD_USAGE - Static variable in class org.apache.hadoop.hbase.util.LoadTestTool
- OPT_MULTIGET - Static variable in class org.apache.hadoop.hbase.util.LoadTestTool
- OPT_MULTIPUT - Static variable in class org.apache.hadoop.hbase.util.LoadTestTool
- OPT_NUM_KEYS - Static variable in class org.apache.hadoop.hbase.util.LoadTestTool
- OPT_NUM_REGIONS_PER_SERVER - Static variable in class org.apache.hadoop.hbase.util.LoadTestTool
- OPT_NUM_REGIONS_PER_SERVER_USAGE - Static variable in class org.apache.hadoop.hbase.util.LoadTestTool
- OPT_READ - Static variable in class org.apache.hadoop.hbase.util.LoadTestTool
- OPT_READER - Static variable in class org.apache.hadoop.hbase.util.LoadTestTool
- OPT_READER_USAGE - Static variable in class org.apache.hadoop.hbase.util.LoadTestTool
- OPT_REGION_REPLICA_ID - Static variable in class org.apache.hadoop.hbase.util.LoadTestTool
- OPT_REGION_REPLICA_ID_USAGE - Static variable in class org.apache.hadoop.hbase.util.LoadTestTool
- OPT_REGION_REPLICATION - Static variable in class org.apache.hadoop.hbase.util.LoadTestTool
- OPT_REGION_REPLICATION_USAGE - Static variable in class org.apache.hadoop.hbase.util.LoadTestTool
- OPT_SKIP_INIT - Static variable in class org.apache.hadoop.hbase.util.LoadTestTool
- OPT_START_KEY - Static variable in class org.apache.hadoop.hbase.util.LoadTestTool
- OPT_TABLE_NAME - Static variable in class org.apache.hadoop.hbase.util.LoadTestTool
- OPT_UPDATE - Static variable in class org.apache.hadoop.hbase.util.LoadTestTool
- OPT_UPDATER - Static variable in class org.apache.hadoop.hbase.util.LoadTestTool
- OPT_UPDATER_USAGE - Static variable in class org.apache.hadoop.hbase.util.LoadTestTool
- OPT_USAGE_BLOOM - Static variable in class org.apache.hadoop.hbase.util.LoadTestTool
- OPT_USAGE_COMPRESSION - Static variable in class org.apache.hadoop.hbase.util.LoadTestTool
- OPT_USAGE_IN_MEMORY - Static variable in class org.apache.hadoop.hbase.util.LoadTestTool
- OPT_USAGE_LOAD - Static variable in class org.apache.hadoop.hbase.util.LoadTestTool
-
Usage string for the load option
- OPT_USAGE_READ - Static variable in class org.apache.hadoop.hbase.util.LoadTestTool
-
Usage string for the read option
- OPT_USAGE_UPDATE - Static variable in class org.apache.hadoop.hbase.util.LoadTestTool
-
Usage string for the update option
- OPT_VERBOSE - Static variable in class org.apache.hadoop.hbase.util.LoadTestTool
- OPT_WRITE - Static variable in class org.apache.hadoop.hbase.util.LoadTestTool
- OPT_WRITER - Static variable in class org.apache.hadoop.hbase.util.LoadTestTool
- OPT_WRITER_USAGE - Static variable in class org.apache.hadoop.hbase.util.LoadTestTool
- OPT_ZK_PARENT_NODE - Static variable in class org.apache.hadoop.hbase.util.LoadTestTool
- OPT_ZK_QUORUM - Static variable in class org.apache.hadoop.hbase.util.LoadTestTool
- optimalFunctionCount(int, long) - Static method in class org.apache.hadoop.hbase.util.BloomFilterUtil
- OPTIMIZED_MOB_COMPACTION_TYPE - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
-
Mob compaction type: "full", "optimized" "full" - run full major compaction (during migration) "optimized" - optimized version for use case with infrequent updates/deletes
- OPTION_BACKUP_LIST_DESC - Static variable in interface org.apache.hadoop.hbase.backup.BackupRestoreConstants
- OPTION_BANDWIDTH - Static variable in interface org.apache.hadoop.hbase.backup.BackupRestoreConstants
- OPTION_BANDWIDTH_DESC - Static variable in interface org.apache.hadoop.hbase.backup.BackupRestoreConstants
- OPTION_CHECK - Static variable in interface org.apache.hadoop.hbase.backup.BackupRestoreConstants
- OPTION_CHECK_DESC - Static variable in interface org.apache.hadoop.hbase.backup.BackupRestoreConstants
- OPTION_DEBUG - Static variable in interface org.apache.hadoop.hbase.backup.BackupRestoreConstants
- OPTION_DEBUG_DESC - Static variable in interface org.apache.hadoop.hbase.backup.BackupRestoreConstants
- OPTION_IGNORECHECKSUM - Static variable in interface org.apache.hadoop.hbase.backup.BackupRestoreConstants
- OPTION_IGNORECHECKSUM_DESC - Static variable in interface org.apache.hadoop.hbase.backup.BackupRestoreConstants
- OPTION_KEEP - Static variable in interface org.apache.hadoop.hbase.backup.BackupRestoreConstants
- OPTION_KEEP_DESC - Static variable in interface org.apache.hadoop.hbase.backup.BackupRestoreConstants
- OPTION_LIST - Static variable in interface org.apache.hadoop.hbase.backup.BackupRestoreConstants
- OPTION_OVERWRITE - Static variable in interface org.apache.hadoop.hbase.backup.BackupRestoreConstants
- OPTION_OVERWRITE_DESC - Static variable in interface org.apache.hadoop.hbase.backup.BackupRestoreConstants
- OPTION_PATH - Static variable in interface org.apache.hadoop.hbase.backup.BackupRestoreConstants
- OPTION_PATH_DESC - Static variable in interface org.apache.hadoop.hbase.backup.BackupRestoreConstants
- OPTION_RECORD_NUMBER - Static variable in interface org.apache.hadoop.hbase.backup.BackupRestoreConstants
- OPTION_RECORD_NUMBER_DESC - Static variable in interface org.apache.hadoop.hbase.backup.BackupRestoreConstants
- OPTION_SET - Static variable in interface org.apache.hadoop.hbase.backup.BackupRestoreConstants
- OPTION_SET_BACKUP_DESC - Static variable in interface org.apache.hadoop.hbase.backup.BackupRestoreConstants
- OPTION_SET_DESC - Static variable in interface org.apache.hadoop.hbase.backup.BackupRestoreConstants
- OPTION_SET_RESTORE_DESC - Static variable in interface org.apache.hadoop.hbase.backup.BackupRestoreConstants
- OPTION_TABLE - Static variable in interface org.apache.hadoop.hbase.backup.BackupRestoreConstants
- OPTION_TABLE_DESC - Static variable in interface org.apache.hadoop.hbase.backup.BackupRestoreConstants
- OPTION_TABLE_LIST_DESC - Static variable in interface org.apache.hadoop.hbase.backup.BackupRestoreConstants
- OPTION_TABLE_MAPPING - Static variable in interface org.apache.hadoop.hbase.backup.BackupRestoreConstants
- OPTION_TABLE_MAPPING_DESC - Static variable in interface org.apache.hadoop.hbase.backup.BackupRestoreConstants
- OPTION_WORKERS - Static variable in interface org.apache.hadoop.hbase.backup.BackupRestoreConstants
- OPTION_WORKERS_DESC - Static variable in interface org.apache.hadoop.hbase.backup.BackupRestoreConstants
- OPTION_YARN_QUEUE_NAME - Static variable in interface org.apache.hadoop.hbase.backup.BackupRestoreConstants
- OPTION_YARN_QUEUE_NAME_DESC - Static variable in interface org.apache.hadoop.hbase.backup.BackupRestoreConstants
- OPTION_YARN_QUEUE_NAME_RESTORE_DESC - Static variable in interface org.apache.hadoop.hbase.backup.BackupRestoreConstants
- options - Variable in class org.apache.hadoop.hbase.util.AbstractHBaseTool
- OptionsOrderComparator() - Constructor for class org.apache.hadoop.hbase.util.AbstractHBaseTool.OptionsOrderComparator
- optionToConf(CommandLine, String, Configuration, String) - Static method in class org.apache.hadoop.hbase.thrift.ThriftServer
- OR - Enum constant in enum class org.apache.hadoop.hbase.client.LogQueryFilter.FilterByOperator
-
Deprecated.
- OR - Enum constant in enum class org.apache.hadoop.hbase.filter.BitComparator.BitwiseOp
-
or
- OR - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
OR Byte Array
- OR_ARRAY - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
OR Array
- OR_BUFFER - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
- order - Variable in class org.apache.hadoop.hbase.types.OrderedBytesBase
- order - Variable in class org.apache.hadoop.hbase.types.RawBytes
- order - Variable in class org.apache.hadoop.hbase.types.RawString
- org.apache.hadoop.hbase.util.Order - Enum Class in org.apache.hadoop.hbase.util
-
Used to describe or modify the lexicographical sort order of a
byte[]
. - org.apache.hadoop.hbase.types.OrderedBlob - Class in org.apache.hadoop.hbase.types
-
A
byte[]
of variable-length. - OrderedBlob(Order) - Constructor for class org.apache.hadoop.hbase.types.OrderedBlob
-
Creates a new
byte[]
with variable length. - org.apache.hadoop.hbase.types.OrderedBlobVar - Class in org.apache.hadoop.hbase.types
-
An alternative to
OrderedBlob
for use byStruct
fields that do not terminate the fields list. - OrderedBlobVar(Order) - Constructor for class org.apache.hadoop.hbase.types.OrderedBlobVar
- org.apache.hadoop.hbase.util.OrderedBytes - Class in org.apache.hadoop.hbase.util
-
Utility class that handles ordered byte arrays.
- OrderedBytes() - Constructor for class org.apache.hadoop.hbase.util.OrderedBytes
- org.apache.hadoop.hbase.types.OrderedBytesBase<T> - Class in org.apache.hadoop.hbase.types
-
Base class for data types backed by the
OrderedBytes
encoding implementations. - OrderedBytesBase(Order) - Constructor for class org.apache.hadoop.hbase.types.OrderedBytesBase
- org.apache.hadoop.hbase.types.OrderedFloat32 - Class in org.apache.hadoop.hbase.types
-
A
float
of 32-bits using a fixed-length encoding. - OrderedFloat32(Order) - Constructor for class org.apache.hadoop.hbase.types.OrderedFloat32
-
Creates a new 32-bit
float
with a fixed-length encoding. - org.apache.hadoop.hbase.types.OrderedFloat64 - Class in org.apache.hadoop.hbase.types
-
A
double
of 64-bits using a fixed-length encoding. - OrderedFloat64(Order) - Constructor for class org.apache.hadoop.hbase.types.OrderedFloat64
-
Creates a new 64-bite
double
with a fixed-length encoding. - org.apache.hadoop.hbase.types.OrderedInt16 - Class in org.apache.hadoop.hbase.types
-
A
short
of 16-bits using a fixed-length encoding. - OrderedInt16(Order) - Constructor for class org.apache.hadoop.hbase.types.OrderedInt16
-
Creates a new 16-bit
short
with a fixed-length encoding. - org.apache.hadoop.hbase.types.OrderedInt32 - Class in org.apache.hadoop.hbase.types
-
An
int
of 32-bits using a fixed-length encoding. - OrderedInt32(Order) - Constructor for class org.apache.hadoop.hbase.types.OrderedInt32
-
Creates a new 32-bit
int
with a fixed-length encoding. - org.apache.hadoop.hbase.types.OrderedInt64 - Class in org.apache.hadoop.hbase.types
-
A
long
of 64-bits using a fixed-length encoding. - OrderedInt64(Order) - Constructor for class org.apache.hadoop.hbase.types.OrderedInt64
-
Creates a new 64-bit
long
with a fixed-length encoding. - org.apache.hadoop.hbase.types.OrderedInt8 - Class in org.apache.hadoop.hbase.types
-
A
byte
of 8-bits using a fixed-length encoding. - OrderedInt8(Order) - Constructor for class org.apache.hadoop.hbase.types.OrderedInt8
-
Creates a new 8-bit
byte
with a fixed-length encoding. - org.apache.hadoop.hbase.types.OrderedNumeric - Class in org.apache.hadoop.hbase.types
-
An
Number
of arbitrary precision and variable-length encoding. - OrderedNumeric(Order) - Constructor for class org.apache.hadoop.hbase.types.OrderedNumeric
-
Creates a new
Number
of arbitrary precision and variable-length encoding. - org.apache.hadoop.hbase.types.OrderedString - Class in org.apache.hadoop.hbase.types
-
A
String
of variable-length. - OrderedString(Order) - Constructor for class org.apache.hadoop.hbase.types.OrderedString
-
Creates a new variable-length
String
. - org.apache.hadoop.hbase - package org.apache.hadoop.hbase
- org.apache.hadoop.hbase.backup - package org.apache.hadoop.hbase.backup
- org.apache.hadoop.hbase.chaos - package org.apache.hadoop.hbase.chaos
- org.apache.hadoop.hbase.client - package org.apache.hadoop.hbase.client
-
Provides HBase Client
- org.apache.hadoop.hbase.client.backoff - package org.apache.hadoop.hbase.client.backoff
- org.apache.hadoop.hbase.client.example - package org.apache.hadoop.hbase.client.example
- org.apache.hadoop.hbase.client.locking - package org.apache.hadoop.hbase.client.locking
- org.apache.hadoop.hbase.client.replication - package org.apache.hadoop.hbase.client.replication
- org.apache.hadoop.hbase.client.security - package org.apache.hadoop.hbase.client.security
- org.apache.hadoop.hbase.client.trace - package org.apache.hadoop.hbase.client.trace
- org.apache.hadoop.hbase.codec - package org.apache.hadoop.hbase.codec
- org.apache.hadoop.hbase.conf - package org.apache.hadoop.hbase.conf
- org.apache.hadoop.hbase.coordination - package org.apache.hadoop.hbase.coordination
- org.apache.hadoop.hbase.coprocessor - package org.apache.hadoop.hbase.coprocessor
-
Table of Contents
- org.apache.hadoop.hbase.errorhandling - package org.apache.hadoop.hbase.errorhandling
- org.apache.hadoop.hbase.exceptions - package org.apache.hadoop.hbase.exceptions
- org.apache.hadoop.hbase.favored - package org.apache.hadoop.hbase.favored
- org.apache.hadoop.hbase.filter - package org.apache.hadoop.hbase.filter
-
Provides row-level filters applied to HRegion scan results during calls to
ResultScanner.next()
. - org.apache.hadoop.hbase.hbtop - package org.apache.hadoop.hbase.hbtop
- org.apache.hadoop.hbase.hbtop.field - package org.apache.hadoop.hbase.hbtop.field
- org.apache.hadoop.hbase.hbtop.mode - package org.apache.hadoop.hbase.hbtop.mode
- org.apache.hadoop.hbase.hbtop.screen - package org.apache.hadoop.hbase.hbtop.screen
- org.apache.hadoop.hbase.hbtop.screen.field - package org.apache.hadoop.hbase.hbtop.screen.field
- org.apache.hadoop.hbase.hbtop.screen.help - package org.apache.hadoop.hbase.hbtop.screen.help
- org.apache.hadoop.hbase.hbtop.screen.mode - package org.apache.hadoop.hbase.hbtop.screen.mode
- org.apache.hadoop.hbase.hbtop.screen.top - package org.apache.hadoop.hbase.hbtop.screen.top
- org.apache.hadoop.hbase.hbtop.terminal - package org.apache.hadoop.hbase.hbtop.terminal
- org.apache.hadoop.hbase.hbtop.terminal.impl - package org.apache.hadoop.hbase.hbtop.terminal.impl
- org.apache.hadoop.hbase.hbtop.terminal.impl.batch - package org.apache.hadoop.hbase.hbtop.terminal.impl.batch
- org.apache.hadoop.hbase.http - package org.apache.hadoop.hbase.http
-
Copied from hadoop source code.
See https://issues.apache.org/jira/browse/HADOOP-10232 to know why. - org.apache.hadoop.hbase.http.conf - package org.apache.hadoop.hbase.http.conf
- org.apache.hadoop.hbase.http.gson - package org.apache.hadoop.hbase.http.gson
- org.apache.hadoop.hbase.http.jersey - package org.apache.hadoop.hbase.http.jersey
- org.apache.hadoop.hbase.http.jmx - package org.apache.hadoop.hbase.http.jmx
-
This package provides access to JMX primarily through the
JMXJsonServlet
class. - org.apache.hadoop.hbase.http.lib - package org.apache.hadoop.hbase.http.lib
-
This package provides user-selectable (via configuration) classes that add functionality to the web UI.
- org.apache.hadoop.hbase.http.log - package org.apache.hadoop.hbase.http.log
- org.apache.hadoop.hbase.http.prometheus - package org.apache.hadoop.hbase.http.prometheus
- org.apache.hadoop.hbase.io - package org.apache.hadoop.hbase.io
- org.apache.hadoop.hbase.io.asyncfs - package org.apache.hadoop.hbase.io.asyncfs
- org.apache.hadoop.hbase.io.asyncfs.monitor - package org.apache.hadoop.hbase.io.asyncfs.monitor
- org.apache.hadoop.hbase.io.compress - package org.apache.hadoop.hbase.io.compress
- org.apache.hadoop.hbase.io.crypto - package org.apache.hadoop.hbase.io.crypto
- org.apache.hadoop.hbase.io.crypto.aes - package org.apache.hadoop.hbase.io.crypto.aes
- org.apache.hadoop.hbase.io.crypto.tls - package org.apache.hadoop.hbase.io.crypto.tls
- org.apache.hadoop.hbase.io.encoding - package org.apache.hadoop.hbase.io.encoding
- org.apache.hadoop.hbase.io.hadoopbackport - package org.apache.hadoop.hbase.io.hadoopbackport
- org.apache.hadoop.hbase.io.hfile - package org.apache.hadoop.hbase.io.hfile
-
Provides implementations of
HFile
and HFileBlockCache
. - org.apache.hadoop.hbase.io.util - package org.apache.hadoop.hbase.io.util
- org.apache.hadoop.hbase.ipc - package org.apache.hadoop.hbase.ipc
-
Tools to help define network clients and servers.
- org.apache.hadoop.hbase.log - package org.apache.hadoop.hbase.log
- org.apache.hadoop.hbase.logging - package org.apache.hadoop.hbase.logging
- org.apache.hadoop.hbase.mapred - package org.apache.hadoop.hbase.mapred
-
Provides HBase MapReduce Input/OutputFormats, a table indexing MapReduce job, and utility methods.
- org.apache.hadoop.hbase.mapreduce - package org.apache.hadoop.hbase.mapreduce
-
Provides HBase MapReduce Input/OutputFormats, a table indexing MapReduce job, and utility methods.
- org.apache.hadoop.hbase.master - package org.apache.hadoop.hbase.master
- org.apache.hadoop.hbase.metrics - package org.apache.hadoop.hbase.metrics
-
Metrics API for HBase.
- org.apache.hadoop.hbase.mob - package org.apache.hadoop.hbase.mob
- org.apache.hadoop.hbase.mob.mapreduce - package org.apache.hadoop.hbase.mob.mapreduce
- org.apache.hadoop.hbase.namequeues - package org.apache.hadoop.hbase.namequeues
- org.apache.hadoop.hbase.namequeues.impl - package org.apache.hadoop.hbase.namequeues.impl
- org.apache.hadoop.hbase.namequeues.request - package org.apache.hadoop.hbase.namequeues.request
- org.apache.hadoop.hbase.namequeues.response - package org.apache.hadoop.hbase.namequeues.response
- org.apache.hadoop.hbase.namespace - package org.apache.hadoop.hbase.namespace
- org.apache.hadoop.hbase.net - package org.apache.hadoop.hbase.net
- org.apache.hadoop.hbase.nio - package org.apache.hadoop.hbase.nio
- org.apache.hadoop.hbase.quotas - package org.apache.hadoop.hbase.quotas
- org.apache.hadoop.hbase.quotas.policies - package org.apache.hadoop.hbase.quotas.policies
- org.apache.hadoop.hbase.regionserver - package org.apache.hadoop.hbase.regionserver
- org.apache.hadoop.hbase.regionserver.http - package org.apache.hadoop.hbase.regionserver.http
- org.apache.hadoop.hbase.regionserver.metrics - package org.apache.hadoop.hbase.regionserver.metrics
- org.apache.hadoop.hbase.regionserver.querymatcher - package org.apache.hadoop.hbase.regionserver.querymatcher
- org.apache.hadoop.hbase.regionserver.regionreplication - package org.apache.hadoop.hbase.regionserver.regionreplication
- org.apache.hadoop.hbase.regionserver.storefiletracker - package org.apache.hadoop.hbase.regionserver.storefiletracker
- org.apache.hadoop.hbase.regionserver.throttle - package org.apache.hadoop.hbase.regionserver.throttle
- org.apache.hadoop.hbase.regionserver.wal - package org.apache.hadoop.hbase.regionserver.wal
- org.apache.hadoop.hbase.replication - package org.apache.hadoop.hbase.replication
-
Multi Cluster Replication
- org.apache.hadoop.hbase.rest - package org.apache.hadoop.hbase.rest
-
HBase REST
- org.apache.hadoop.hbase.rest.client - package org.apache.hadoop.hbase.rest.client
- org.apache.hadoop.hbase.rsgroup - package org.apache.hadoop.hbase.rsgroup
- org.apache.hadoop.hbase.security - package org.apache.hadoop.hbase.security
- org.apache.hadoop.hbase.server.trace - package org.apache.hadoop.hbase.server.trace
- org.apache.hadoop.hbase.shaded.protobuf - package org.apache.hadoop.hbase.shaded.protobuf
- org.apache.hadoop.hbase.slowlog - package org.apache.hadoop.hbase.slowlog
- org.apache.hadoop.hbase.snapshot - package org.apache.hadoop.hbase.snapshot
- org.apache.hadoop.hbase.testing - package org.apache.hadoop.hbase.testing
- org.apache.hadoop.hbase.thrift - package org.apache.hadoop.hbase.thrift
-
Provides an HBase Thrift service.
- org.apache.hadoop.hbase.tool.coprocessor - package org.apache.hadoop.hbase.tool.coprocessor
- org.apache.hadoop.hbase.types - package org.apache.hadoop.hbase.types
-
This package provides the definition and implementation of HBase's extensible data type API.
- org.apache.hadoop.hbase.util - package org.apache.hadoop.hbase.util
- org.apache.hadoop.hbase.util.compaction - package org.apache.hadoop.hbase.util.compaction
- org.apache.hadoop.hbase.util.hbck - package org.apache.hadoop.hbase.util.hbck
- org.apache.hadoop.hbase.wal - package org.apache.hadoop.hbase.wal
- org.apache.hadoop.hbase.zookeeper - package org.apache.hadoop.hbase.zookeeper
- org.apache.hadoop.hdfs - package org.apache.hadoop.hdfs
- org.apache.hadoop.metrics2 - package org.apache.hadoop.metrics2
- org.apache.hbase.archetypes.exemplars.client - package org.apache.hbase.archetypes.exemplars.client
-
This package provides fully-functional exemplar Java code demonstrating simple usage of the hbase-client API, for incorporation into a Maven archetype with hbase-client dependency.
- org.apache.hbase.archetypes.exemplars.shaded_client - package org.apache.hbase.archetypes.exemplars.shaded_client
-
This package provides fully-functional exemplar Java code demonstrating simple usage of the hbase-client API, for incorporation into a Maven archetype with hbase-shaded-client dependency.
- ORPHAN_HDFS_REGION - Enum constant in enum class org.apache.hadoop.hbase.util.HbckErrorReporter.ERROR_CODE
-
Deprecated.
- ORPHAN_REGIONS_ON_FS - Static variable in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
- ORPHAN_REGIONS_ON_FS_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
- ORPHAN_REGIONS_ON_RS - Static variable in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
- ORPHAN_REGIONS_ON_RS_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
- ORPHAN_TABLE_STATE - Enum constant in enum class org.apache.hadoop.hbase.util.HbckErrorReporter.ERROR_CODE
-
Deprecated.
- ostream - Variable in class org.apache.hadoop.hbase.io.hfile.HFile.WriterFactory
- OTHER_EXCEPTIONS - Static variable in interface org.apache.hadoop.hbase.metrics.ExceptionTrackingSource
- otherExceptions - Variable in class org.apache.hadoop.hbase.metrics.ExceptionTrackingSourceImpl
- otherExceptions() - Method in interface org.apache.hadoop.hbase.metrics.ExceptionTrackingSource
- otherExceptions() - Method in class org.apache.hadoop.hbase.metrics.ExceptionTrackingSourceImpl
- ourFiles - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
Matches just those wal files that belong to this wal instance.
- out - Variable in class org.apache.hadoop.hbase.codec.BaseEncoder
- outOfOrderException() - Method in interface org.apache.hadoop.hbase.metrics.ExceptionTrackingSource
-
Different types of exceptions
- outOfOrderException() - Method in class org.apache.hadoop.hbase.metrics.ExceptionTrackingSourceImpl
- org.apache.hadoop.hbase.exceptions.OutOfOrderScannerNextException - Exception in org.apache.hadoop.hbase.exceptions
-
Thrown by a RegionServer while doing next() calls on a ResultScanner.
- OutOfOrderScannerNextException() - Constructor for exception org.apache.hadoop.hbase.exceptions.OutOfOrderScannerNextException
- OutOfOrderScannerNextException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.OutOfOrderScannerNextException
- output - Variable in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogWriter
- OUTPUT_CLUSTER - Static variable in class org.apache.hadoop.hbase.mapreduce.TableOutputFormat
-
Optional job parameter to specify a peer cluster.
- OUTPUT_CONF_PREFIX - Static variable in class org.apache.hadoop.hbase.mapreduce.TableOutputFormat
-
Deprecated.Since 3.0.0, will be removed in 4.0.0. You do not need to use this way for specifying configurations any more, you can specify any configuration with the connection uri's queries specified by the
TableOutputFormat.OUTPUT_CLUSTER
parameter. - OUTPUT_TABLE - Static variable in class org.apache.hadoop.hbase.mapred.TableOutputFormat
-
JobConf parameter that specifies the output table
- OUTPUT_TABLE - Static variable in class org.apache.hadoop.hbase.mapreduce.TableOutputFormat
-
Job parameter that specifies the output table.
- outputStream - Variable in class org.apache.hadoop.hbase.io.hfile.HFileWriterImpl
-
FileSystem stream to write into.
- outputStreamFromByteRange(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.types.PBType
-
Create a
CodedOutputStream
from aPositionedByteRange
. - OVERALL_HREGION_FILES - Static variable in class org.apache.hadoop.hbase.HConstants
-
Conf key for if we should sum overall region files size when check to split
- overallHRegionFiles - Variable in class org.apache.hadoop.hbase.regionserver.ConstantSizeRegionSplitPolicy
- OVERLAP_IN_REGION_CHAIN - Enum constant in enum class org.apache.hadoop.hbase.util.HbckErrorReporter.ERROR_CODE
-
Deprecated.
- overlappingKeys(byte[], byte[], byte[], byte[]) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
Returns true if the first range start1...end1 overlaps with the second range start2...end2, assuming the byte arrays represent row keys
- OVERLAPS - Static variable in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
- OVERLAPS_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
- Owned(ServerName) - Constructor for class org.apache.hadoop.hbase.SplitLogTask.Owned
-
Deprecated.
- ownerToString() - Method in class org.apache.hadoop.hbase.quotas.QuotaSettings
P
- P - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
ASCII code for 'P'
- org.apache.hadoop.hbase.metrics.PackageMarker - Annotation Interface in org.apache.hadoop.hbase.metrics
-
This is a dummy annotation that forces javac to produce output for otherwise empty package-info.java.
- padFront(String, char, int) - Static method in class org.apache.hadoop.hbase.util.Strings
-
Push the input string to the right by appending a character before it, usually a space.
- padHead(byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Make a new byte array from a subset of bytes at the head of another, zero padded as desired.
- padTail(byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Make a new byte array from a subset of bytes at the tail of another, zero padded as desired.
- pageDown() - Method in class org.apache.hadoop.hbase.hbtop.screen.field.FieldScreenPresenter
- pageDown() - Method in class org.apache.hadoop.hbase.hbtop.screen.mode.ModeScreenPresenter
- pageDown() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.Paging
- pageDown() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenPresenter
- PageDown - Enum constant in enum class org.apache.hadoop.hbase.hbtop.terminal.KeyPress.Type
- org.apache.hadoop.hbase.filter.PageFilter - Class in org.apache.hadoop.hbase.filter
-
Implementation of Filter interface that limits results to a specific page size.
- PageFilter(long) - Constructor for class org.apache.hadoop.hbase.filter.PageFilter
-
Constructor that takes a maximum page size.
- pageUp() - Method in class org.apache.hadoop.hbase.hbtop.screen.field.FieldScreenPresenter
- pageUp() - Method in class org.apache.hadoop.hbase.hbtop.screen.mode.ModeScreenPresenter
- pageUp() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.Paging
- pageUp() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenPresenter
- PageUp - Enum constant in enum class org.apache.hadoop.hbase.hbtop.terminal.KeyPress.Type
- org.apache.hadoop.hbase.hbtop.screen.top.Paging - Class in org.apache.hadoop.hbase.hbtop.screen.top
-
Utility class for paging for the metrics.
- Paging() - Constructor for class org.apache.hadoop.hbase.hbtop.screen.top.Paging
- org.apache.hadoop.hbase.util.Pair<T1,
T2> - Class in org.apache.hadoop.hbase.util -
A generic class for pairs.
- Pair() - Constructor for class org.apache.hadoop.hbase.util.Pair
-
Default constructor.
- Pair(T1, T2) - Constructor for class org.apache.hadoop.hbase.util.Pair
-
Constructor
- org.apache.hadoop.hbase.util.PairOfSameType<T> - Class in org.apache.hadoop.hbase.util
-
A generic, immutable class for pairs of objects both of type
T
. - PairOfSameType(T, T) - Constructor for class org.apache.hadoop.hbase.util.PairOfSameType
-
Constructor
- PARALLEL_PREPARE_PUT_STORE_MULTIPLIER - Static variable in class org.apache.hadoop.hbase.regionserver.throttle.StoreHotnessProtector
- PARALLEL_PUT_STORE_THREADS_LIMIT - Static variable in class org.apache.hadoop.hbase.regionserver.throttle.StoreHotnessProtector
- PARALLEL_PUT_STORE_THREADS_LIMIT_MIN_COLUMN_COUNT - Static variable in class org.apache.hadoop.hbase.regionserver.throttle.StoreHotnessProtector
- param - Variable in class org.apache.hadoop.hbase.ipc.ServerCall
- parent - Variable in class org.apache.hadoop.hbase.util.ClassLoaderBase
-
Parent class loader.
- parse(byte[]) - Static method in class org.apache.hadoop.hbase.zookeeper.MasterAddressTracker
- parse(byte[], int) - Method in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
- parse(byte[], int, int) - Static method in enum class org.apache.hadoop.hbase.io.hfile.BlockType
- parse(String) - Static method in class org.apache.hadoop.hbase.replication.ReplicationGroupOffset
- parse(String) - Static method in class org.apache.hadoop.hbase.replication.ReplicationQueueId
- parse(String, boolean) - Static method in class org.apache.hadoop.hbase.hbtop.RecordFilter
- parse(String, List<Field>, boolean) - Static method in class org.apache.hadoop.hbase.hbtop.RecordFilter
- parse(Configuration) - Method in class org.apache.hadoop.hbase.zookeeper.ZKMainServer
- parseArgs(String[]) - Method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
- parseBackReferenceName(String) - Static method in class org.apache.hadoop.hbase.io.HFileLink
- parseCell() - Method in class org.apache.hadoop.hbase.codec.BaseDecoder
-
Extract a Cell.
- parseCell() - Method in class org.apache.hadoop.hbase.codec.KeyValueCodec.KeyValueDecoder
- parseCell() - Method in class org.apache.hadoop.hbase.codec.KeyValueCodecWithTags.KeyValueDecoder
- parseColumn(byte[]) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Splits a column in
family:qualifier
form into separate byte arrays. - parseCommandLine(CommandLine, Options) - Method in class org.apache.hadoop.hbase.thrift.ThriftServer
- parseComparator(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Splits a column in comparatorType:comparatorValue form into separate byte arrays
- org.apache.hadoop.hbase.filter.ParseConstants - Class in org.apache.hadoop.hbase.filter
-
ParseConstants holds a bunch of constants related to parsing Filter Strings Used by
ParseFilter
- ParseConstants() - Constructor for class org.apache.hadoop.hbase.filter.ParseConstants
- parseDate(String) - Static method in class org.apache.hadoop.hbase.mob.MobUtils
-
Parses the string to a date.
- parseDelimitedFrom(byte[], int, int) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Parses all the RegionInfo instances from the passed in stream until EOF.
- parseDelimitedFrom(InputStream, Parser<T>) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
This is a wrapper of the PB message's parseDelimitedFrom.
- org.apache.hadoop.hbase.filter.ParseFilter - Class in org.apache.hadoop.hbase.filter
-
This class allows a user to specify a filter via a string The string is parsed using the methods of this class and a filter object is constructed.
- ParseFilter() - Constructor for class org.apache.hadoop.hbase.filter.ParseFilter
- parseFilterString(byte[]) - Method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Parses the filterString and constructs a filter using it
- parseFilterString(String) - Method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Parses the filterString and constructs a filter using it
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
- parseFrom(byte[]) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Returns A deserialized
RegionInfo
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
The input should be created by
TableDescriptorBuilder.toByteArray(org.apache.hadoop.hbase.client.TableDescriptor)
. - parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.ClusterId
-
Parse the serialized representation of the
ClusterId
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.BigDecimalComparator
-
Parse a serialized representation of
BigDecimalComparator
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.BinaryComparator
-
Parse a serialized representation of
BinaryComparator
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.BinaryComponentComparator
-
Parse a serialized representation of
BinaryComponentComparator
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.BinaryPrefixComparator
-
Parse a serialized representation of
BinaryPrefixComparator
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.BitComparator
-
Parse a serialized representation of
BitComparator
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ByteArrayComparable
-
Parse a serialized representation of
ByteArrayComparable
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
-
Parse a serialized representation of
ColumnCountGetFilter
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
-
Parse a serialized representation of
ColumnPaginationFilter
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ColumnPrefixFilter
-
Parses a serialized representation of the
ColumnPrefixFilter
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
-
Parse a serialized representation of
ColumnRangeFilter
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ColumnValueFilter
-
Parse a serialized representation of
ColumnValueFilter
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
-
Parse a seralized representation of
DependentColumnFilter
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.FamilyFilter
-
Parse the serialized representation of
FamilyFilter
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.Filter
-
Concrete implementers can signal a failure condition in their code by throwing an
IOException
. - parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.FilterAllFilter
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.FilterList
-
Parse a seralized representation of
FilterList
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.FilterWrapper
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
-
Parse a serialized representation of
FirstKeyOnlyFilter
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.FuzzyRowFilter
-
Parse a serialized representation of
FuzzyRowFilter
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.InclusiveStopFilter
-
Parse a serialized representation of
InclusiveStopFilter
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter
-
Parse a serialized representation of
KeyOnlyFilter
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.LongComparator
-
Parses a serialized representation of
LongComparator
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
-
Parse a serialized representation of
MultipleColumnPrefixFilter
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter
-
Parse a serialized representation of
MultiRowRangeFilter
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.NullComparator
-
Parse the serialized representation of
NullComparator
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.PageFilter
-
Parse a serialized representation of
PageFilter
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.PrefixFilter
-
Parse a serialized representation of
PrefixFilter
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.QualifierFilter
-
Parse a serialized representation of
QualifierFilter
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.RandomRowFilter
-
Parse a serialized representation of
RandomRowFilter
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.RegexStringComparator
-
Parse a serialized representation of
RegexStringComparator
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.RowFilter
-
Parse a serialized representation of
RowFilter
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter
-
Parse a serialized representation of
SingleColumnValueExcludeFilter
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
Parse a serialized representation of
SingleColumnValueFilter
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.SkipFilter
-
Parse a serialized representation of
SkipFilter
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.SubstringComparator
-
Parse a serialized representation of
SubstringComparator
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.TimestampsFilter
-
Parse a serialized representation of
TimestampsFilter
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ValueFilter
-
Parse a serialized representation of
ValueFilter
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
-
Parse a serialized representation of
WhileMatchFilter
- parseFrom(byte[]) - Method in class org.apache.hadoop.hbase.master.BooleanStateStore
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker
- parseFrom(byte[]) - Static method in enum class org.apache.hadoop.hbase.replication.SyncReplicationState
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.SplitLogTask
-
Deprecated.
- parseFrom(byte[], int, int) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Parse a serialized representation of
RegionInfo
- parseFrom(byte[], TimeRangeTracker.Type) - Static method in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker
- parseFrom(DataInputStream) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Parses an RegionInfo instance from the passed in stream.
- parseFrom(TableName, byte[]) - Static method in class org.apache.hadoop.hbase.client.TableState
- parseFromOrNull(byte[]) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Returns A deserialized
RegionInfo
or null if we failed deserialize or passed bytes null - parseFromOrNull(byte[], int, int) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Returns A deserialized
RegionInfo
or null if we failed deserialize or passed bytes null - parseHashType(String) - Static method in class org.apache.hadoop.hbase.util.Hash
-
This utility method converts String representation of hash function name to a symbolic constant.
- parseHostname(String) - Static method in class org.apache.hadoop.hbase.util.Addressing
-
Parse the hostname portion of a host-and-port string
- parseInt(String, int, int) - Static method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
- parseLong(String, long, long) - Static method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
-
Parse a number and enforce a range.
- parseMasterAddrs(Configuration) - Static method in class org.apache.hadoop.hbase.client.MasterRegistry
-
Deprecated.Parses the list of master addresses from the provided configuration.
- parseMasterServerName(String) - Static method in class org.apache.hadoop.hbase.ZNodeClearer
-
See HBASE-14861.
- parseMetaRegionStateFrom(byte[], int) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Get the Meta region state from the passed data bytes.
- parseNamespaceResult(String, Result, QuotaTableUtil.NamespaceQuotasVisitor) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
- parseNamespaceResult(Result, QuotaTableUtil.NamespaceQuotasVisitor) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
- parseOptions(String[]) - Method in class org.apache.hadoop.hbase.io.hfile.HFilePrettyPrinter
- parseOptions(String[]) - Method in class org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileListFilePrettyPrinter
- parsePeerFrom(byte[]) - Static method in class org.apache.hadoop.hbase.client.replication.ReplicationPeerConfigUtil
-
Parse the serialized representation of a peer configuration.
- parsePort(String) - Static method in class org.apache.hadoop.hbase.util.Addressing
-
Parse the port portion of a host-and-port string
- parser - Variable in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
- parseRegionInfoFromRegionName(byte[]) - Static method in class org.apache.hadoop.hbase.CatalogFamilyFormat
-
Returns an HRI parsed from this regionName.
- parseRegionName(byte[]) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Separate elements of a regionName.
- parseRegionNameOrReturnNull(byte[]) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Separate elements of a regionName.
- parseResult(Result, QuotaTableUtil.QuotasVisitor) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
- parseResultToCollection(Result, Collection<QuotaSettings>) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
- parseRowKey(byte[], int) - Method in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
-
Return starting position and length of row key from the specified line bytes.
- parseServerName(String) - Static method in class org.apache.hadoop.hbase.ServerName
-
Parse a ServerName from a string
- parseServerNameFrom(byte[]) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Get a ServerName from the passed in data bytes.
- parseServerNameFromWALName(String) - Static method in class org.apache.hadoop.hbase.wal.AbstractFSWALProvider
-
Parse the server name from wal prefix.
- parseSimpleFilterExpression(byte[]) - Method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Constructs a filter object given a simple filter expression
- parseStateAndNewStateFrom(byte[]) - Static method in enum class org.apache.hadoop.hbase.replication.SyncReplicationState
- parseTableCFs(byte[]) - Static method in class org.apache.hadoop.hbase.client.replication.ReplicationPeerConfigUtil
-
Parse bytes into TableCFs.
- parseTableCFsFromConfig(String) - Static method in class org.apache.hadoop.hbase.client.replication.ReplicationPeerConfigUtil
-
Convert tableCFs string into Map.
- parseTableResult(Result, QuotaTableUtil.TableQuotasVisitor) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
- parseTableResult(TableName, Result, QuotaTableUtil.TableQuotasVisitor) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
- parseURIQueries(URI) - Static method in class org.apache.hadoop.hbase.util.Strings
-
Parse the query string of an URI to a key value map.
- parseUserResult(String, Result, QuotaTableUtil.UserQuotasVisitor) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
- parseUserResult(Result, QuotaTableUtil.UserQuotasVisitor) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
- parseVersionedServerName(byte[]) - Static method in class org.apache.hadoop.hbase.ServerName
-
Use this method instantiating a
ServerName
from bytes gotten from a call toServerName.getVersionedBytes()
. - parseWALPositionFrom(byte[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
- passedPrefix - Variable in class org.apache.hadoop.hbase.filter.PrefixFilter
- passesDeleteFamilyBloomFilter(byte[], int, int) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileReader
- passesGeneralRowColBloomFilter(ExtendedCell) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileReader
-
A method for checking Bloom filters.
- passesKeyRangeFilter(Scan) - Method in class org.apache.hadoop.hbase.io.HalfStoreFileReader
- passesKeyRangeFilter(Scan) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileReader
-
Checks whether the given scan rowkey range overlaps with the current storefile's
- password - Variable in class org.apache.hadoop.hbase.io.crypto.KeyStoreKeyProvider
- PASSWORD - Static variable in interface org.apache.hadoop.hbase.io.crypto.KeyProvider
- passwordFile - Variable in class org.apache.hadoop.hbase.io.crypto.KeyStoreKeyProvider
- PASSWORDFILE - Static variable in interface org.apache.hadoop.hbase.io.crypto.KeyProvider
- path - Variable in class org.apache.hadoop.hbase.io.hfile.HFile.WriterFactory
- path - Variable in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
-
Path of file
- path - Variable in class org.apache.hadoop.hbase.io.hfile.HFileWriterImpl
-
May be null if we were passed a stream.
- path - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractProtobufWALReader
- path - Static variable in class org.apache.hadoop.hbase.util.CompressionTest
- PATH_SPEC_ANY - Static variable in class org.apache.hadoop.hbase.http.HttpServerUtil
- pathPrefix - Variable in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
- PAUSE_TIME_WITH_GC_DESC - Static variable in interface org.apache.hadoop.hbase.metrics.JvmPauseMonitorSource
- PAUSE_TIME_WITH_GC_KEY - Static variable in interface org.apache.hadoop.hbase.metrics.JvmPauseMonitorSource
- PAUSE_TIME_WITHOUT_GC_DESC - Static variable in interface org.apache.hadoop.hbase.metrics.JvmPauseMonitorSource
- PAUSE_TIME_WITHOUT_GC_KEY - Static variable in interface org.apache.hadoop.hbase.metrics.JvmPauseMonitorSource
- pauseMonitor - Variable in class org.apache.hadoop.hbase.thrift.ThriftServer
- PB_WAL_COMPLETE_MAGIC - Static variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractProtobufWALReader
- PB_WAL_MAGIC - Static variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractProtobufWALReader
- org.apache.hadoop.hbase.types.PBCell - Class in org.apache.hadoop.hbase.types
-
An example for using protobuf objects with
DataType
API. - PBCell() - Constructor for class org.apache.hadoop.hbase.types.PBCell
- PBIS(InputStream, int) - Constructor for class org.apache.hadoop.hbase.codec.BaseDecoder.PBIS
- pbkdf128(byte[]...) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
-
Return a 128 bit key derived from the concatenation of the supplied arguments using PBKDF2WithHmacSHA1 at 10,000 iterations.
- pbkdf128(String...) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
-
Return a 128 bit key derived from the concatenation of the supplied arguments using PBKDF2WithHmacSHA1 at 10,000 iterations.
- org.apache.hadoop.hbase.types.PBType<T extends org.apache.hbase.thirdparty.com.google.protobuf.Message> - Class in org.apache.hadoop.hbase.types
-
A base-class for
DataType
implementations backed by protobuf. - PBType() - Constructor for class org.apache.hadoop.hbase.types.PBType
- PBUF_TRAILER_MINOR_VERSION - Static variable in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
-
HFile minor version that introduced pbuf filetrailer
- PE_KEY - Static variable in class org.apache.hadoop.hbase.PerformanceEvaluation.EvaluationMapTask
-
configuration parameter name that contains the PE impl
- peek() - Method in class org.apache.hadoop.hbase.ipc.AdaptiveLifoCoDelCallQueue
- peek() - Method in class org.apache.hadoop.hbase.regionserver.KeyValueHeap
- peek() - Method in interface org.apache.hadoop.hbase.regionserver.KeyValueScanner
-
Look at the next Cell in this scanner, but do not iterate scanner.
- peek() - Method in class org.apache.hadoop.hbase.regionserver.SegmentScanner
-
Look at the next Cell in this scanner, but do not iterate the scanner
- peek() - Method in class org.apache.hadoop.hbase.regionserver.SnapshotSegmentScanner
- peek() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
- peek() - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
- peek() - Method in class org.apache.hadoop.hbase.thrift.CallQueue
- peek() - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
- peek() - Method in class org.apache.hadoop.hbase.util.BoundedPriorityBlockingQueue
- peek() - Method in class org.apache.hadoop.hbase.util.CollectionBackedScanner
- peek() - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
Retrieve the next byte from this range without incrementing position.
- peerConfigUpdated(ReplicationPeerConfig) - Method in class org.apache.hadoop.hbase.replication.BaseReplicationEndpoint
- peerConfigUpdated(ReplicationPeerConfig) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeerConfigListener
-
Callback method for when users update the ReplicationPeerConfig for this peer
- PEERS_DIR - Static variable in class org.apache.hadoop.hbase.replication.FSReplicationPeerStorage
- PEERS_DIR_DEFAULT - Static variable in class org.apache.hadoop.hbase.replication.FSReplicationPeerStorage
- PEERS_STATE_ZNODE - Static variable in class org.apache.hadoop.hbase.replication.ZKReplicationPeerStorage
- PEERS_STATE_ZNODE_DEFAULT - Static variable in class org.apache.hadoop.hbase.replication.ZKReplicationPeerStorage
- PEERS_ZNODE - Static variable in class org.apache.hadoop.hbase.replication.ZKReplicationPeerStorage
- PEERS_ZNODE_DEFAULT - Static variable in class org.apache.hadoop.hbase.replication.ZKReplicationPeerStorage
- peerSyncReplicationStateChange(String, SyncReplicationState, SyncReplicationState, int) - Method in class org.apache.hadoop.hbase.wal.AbstractWALProvider
- peersZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZNodePaths
- PEM - Enum constant in enum class org.apache.hadoop.hbase.io.crypto.tls.KeyStoreFileType
- PER_BLOCK_OVERHEAD - Static variable in class org.apache.hadoop.hbase.io.hfile.LruCachedBlock
- PERCENT - Enum constant in enum class org.apache.hadoop.hbase.hbtop.field.FieldValueType
- PERCENT_FILES_LOCAL - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- PERCENT_FILES_LOCAL_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- PERCENT_FILES_LOCAL_SECONDARY_REGIONS - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- PERCENT_FILES_LOCAL_SECONDARY_REGIONS_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- org.apache.hadoop.hbase.client.PerClientRandomNonceGenerator - Class in org.apache.hadoop.hbase.client
-
NonceGenerator implementation that uses client ID hash + random int as nonce group, and random numbers as nonces.
- org.apache.hadoop.hbase.PerformanceEvaluation - Class in org.apache.hadoop.hbase
-
Script used evaluating HBase performance and scalability.
- PerformanceEvaluation(Configuration) - Constructor for class org.apache.hadoop.hbase.PerformanceEvaluation
-
Constructor
- org.apache.hadoop.hbase.PerformanceEvaluation.Counter - Enum Class in org.apache.hadoop.hbase
-
Enum for map metrics.
- org.apache.hadoop.hbase.PerformanceEvaluation.EvaluationMapTask - Class in org.apache.hadoop.hbase
-
MapReduce job that runs a performance evaluation client in each map task.
- org.apache.hadoop.hbase.PerformanceEvaluation.RunResult - Class in org.apache.hadoop.hbase
- org.apache.hadoop.hbase.PerformanceEvaluationCommons - Class in org.apache.hadoop.hbase
-
Code shared by PE tests.
- PerformanceEvaluationCommons() - Constructor for class org.apache.hadoop.hbase.PerformanceEvaluationCommons
- performCompaction(Compactor.FileDetails, InternalScanner, CellSink, long, boolean, ThroughputController, CompactionRequestImpl, CompactionProgress) - Method in class org.apache.hadoop.hbase.mob.DefaultMobStoreCompactor
-
Performs compaction on a column family with the mob flag enabled.
- performFlush(InternalScanner, CellSink, ThroughputController) - Method in class org.apache.hadoop.hbase.regionserver.DefaultStoreFlusher
-
Performs memstore flush, writing data from scanner into sink.
- performMajorCompactionInBatches(Admin, TableDescriptor, ColumnFamilyDescriptor) - Method in class org.apache.hadoop.hbase.mob.MobFileCompactionChore
- performMobFlush(MemStoreSnapshot, long, InternalScanner, StoreFileWriter, MonitoredTask, ThroughputController, Consumer<Path>) - Method in class org.apache.hadoop.hbase.mob.DefaultMobStoreFlusher
-
Flushes the cells in the mob store.
- PERIOD - Static variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
- PERIODIC_REFRESH_INTERVAL_SECS - Static variable in class org.apache.hadoop.hbase.client.RpcConnectionRegistry
- permissionActionsFromString(String) - Static method in class org.apache.hadoop.hbase.thrift.ThriftUtilities
- PERSIST_FLUSHEDSEQUENCEID - Static variable in class org.apache.hadoop.hbase.master.ServerManager
-
see HBASE-20727 if set to true, flushedSequenceIdByRegion and storeFlushedSequenceIdsByRegion will be persisted to HDFS and loaded when master restart to speed up log split
- PERSIST_FLUSHEDSEQUENCEID_DEFAULT - Static variable in class org.apache.hadoop.hbase.master.ServerManager
- persistAll(Connection) - Method in class org.apache.hadoop.hbase.namequeues.impl.BalancerDecisionQueueService
- persistAll(Connection) - Method in class org.apache.hadoop.hbase.namequeues.impl.BalancerRejectionQueueService
- persistAll(Connection) - Method in class org.apache.hadoop.hbase.namequeues.impl.SlowLogQueueService
-
Add all slowLog events to system table.
- persistAll(Connection) - Method in interface org.apache.hadoop.hbase.namequeues.NamedQueueService
-
Add all in memory queue records to system table.
- persistAll(Connection) - Method in class org.apache.hadoop.hbase.namequeues.WALEventTrackerQueueService
- persistAll(NamedQueuePayload.NamedQueueEvent, Connection) - Method in class org.apache.hadoop.hbase.namequeues.NamedQueueRecorder
-
Add all in memory queue records to system table.
- PETABYTE - Enum constant in enum class org.apache.hadoop.hbase.Size.Unit
- PHOENIX - Static variable in class org.apache.hadoop.hbase.HBaseInterfaceAudience
- PING_CALL_ID - Static variable in interface org.apache.hadoop.hbase.ipc.RpcClient
- PipelineController() - Constructor for class org.apache.hadoop.hbase.wal.WALSplitter.PipelineController
- pipelineThreshold - Variable in class org.apache.hadoop.hbase.regionserver.MemStoreCompactionStrategy
- PKCS12 - Enum constant in enum class org.apache.hadoop.hbase.io.crypto.tls.KeyStoreFileType
- placePrimaryRSAsRoundRobin(Map<ServerName, List<RegionInfo>>, Map<RegionInfo, ServerName>, List<RegionInfo>) - Method in class org.apache.hadoop.hbase.favored.FavoredNodeAssignmentHelper
- placeSecondaryAndTertiaryRS(Map<RegionInfo, ServerName>) - Method in class org.apache.hadoop.hbase.favored.FavoredNodeAssignmentHelper
- placeSecondaryAndTertiaryWithRestrictions(Map<RegionInfo, ServerName>) - Method in class org.apache.hadoop.hbase.favored.FavoredNodeAssignmentHelper
-
For regions that share the primary, avoid placing the secondary and tertiary on a same RS.
- org.apache.hadoop.hbase.PleaseHoldException - Exception in org.apache.hadoop.hbase
-
This exception is thrown by the master when a region server was shut down and restarted so fast that the master still hasn't processed the server shutdown of the first instance, or when master is initializing and client call admin operations, or when an operation is performed on a region server that is still starting.
- PleaseHoldException(String) - Constructor for exception org.apache.hadoop.hbase.PleaseHoldException
- PleaseHoldException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.PleaseHoldException
- PleaseHoldException(Throwable) - Constructor for exception org.apache.hadoop.hbase.PleaseHoldException
- org.apache.hadoop.hbase.PleaseRestartMasterException - Exception in org.apache.hadoop.hbase
-
Thrown if the master requires restart.
- PleaseRestartMasterException(String) - Constructor for exception org.apache.hadoop.hbase.PleaseRestartMasterException
- PLUGGABLE_CALL_QUEUE_CLASS_NAME - Static variable in class org.apache.hadoop.hbase.ipc.RpcExecutor
- PLUGGABLE_CALL_QUEUE_WITH_FAST_PATH_ENABLED - Static variable in class org.apache.hadoop.hbase.ipc.RpcExecutor
- PluggableBlockingQueue - Class in org.apache.hadoop.hbase.ipc
-
Abstract class template for defining a pluggable blocking queue implementation to be used by the 'pluggable' call queue type in the RpcExecutor.
- PluggableBlockingQueue(int, PriorityFunction, Configuration) - Constructor for class org.apache.hadoop.hbase.ipc.PluggableBlockingQueue
- org.apache.hadoop.hbase.ipc.PluggableRpcQueueNotFound - Exception in org.apache.hadoop.hbase.ipc
-
Internal runtime error type to indicate the RpcExecutor failed to execute a `pluggable` call queue type.
- PluggableRpcQueueNotFound(String) - Constructor for exception org.apache.hadoop.hbase.ipc.PluggableRpcQueueNotFound
- pluralize(int) - Static method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
- pluralize(Collection<?>) - Static method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
- plus(FieldValue) - Method in class org.apache.hadoop.hbase.hbtop.field.FieldValue
- poll() - Method in class org.apache.hadoop.hbase.io.hfile.LruCachedBlockQueue
-
Returns The next element in this queue, or
null
if the queue is empty. - poll() - Method in class org.apache.hadoop.hbase.ipc.AdaptiveLifoCoDelCallQueue
- poll() - Method in class org.apache.hadoop.hbase.thrift.CallQueue
- poll() - Method in class org.apache.hadoop.hbase.util.BoundedPriorityBlockingQueue
- poll(long, TimeUnit) - Method in class org.apache.hadoop.hbase.ipc.AdaptiveLifoCoDelCallQueue
- poll(long, TimeUnit) - Method in class org.apache.hadoop.hbase.thrift.CallQueue
- poll(long, TimeUnit) - Method in class org.apache.hadoop.hbase.util.BoundedCompletionService
- poll(long, TimeUnit) - Method in class org.apache.hadoop.hbase.util.BoundedPriorityBlockingQueue
- poll(long, TimeUnit) - Method in class org.apache.hadoop.hbase.util.StealJobQueue
- pollFirst() - Method in class org.apache.hadoop.hbase.regionserver.CellSet
- pollFirstEntry() - Method in class org.apache.hadoop.hbase.regionserver.CellFlatMap
- pollFirstEntry() - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
- pollKeyPress() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.batch.BatchTerminal
- pollKeyPress() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.TerminalImpl
- pollKeyPress() - Method in interface org.apache.hadoop.hbase.hbtop.terminal.Terminal
- pollLast() - Method in class org.apache.hadoop.hbase.io.hfile.LruCachedBlockQueue
-
Returns The last element in this queue, or
null
if the queue is empty. - pollLast() - Method in class org.apache.hadoop.hbase.regionserver.CellSet
- pollLastEntry() - Method in class org.apache.hadoop.hbase.regionserver.CellFlatMap
- pollLastEntry() - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
- pollRealKV() - Method in class org.apache.hadoop.hbase.regionserver.KeyValueHeap
-
Fetches the top sub-scanner from the priority queue, ensuring that a real seek has been done on it.
- pool(ExecutorService) - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
-
Deprecated.Since 3.0.0-alpha-2, will be removed in 4.0.0. You can not set it anymore. BufferedMutator will use Connection's ExecutorService.
- POOL_INITIAL_SIZE_DEFAULT - Static variable in interface org.apache.hadoop.hbase.regionserver.MemStoreLAB
- POOL_MAX_SIZE_DEFAULT - Static variable in interface org.apache.hadoop.hbase.regionserver.MemStoreLAB
- org.apache.hadoop.hbase.util.PoolMap<K,
V> - Class in org.apache.hadoop.hbase.util -
The
PoolMap
maps a key to a collection of values, the elements of which are managed by a pool. - PoolMap(PoolMap.PoolType, int) - Constructor for class org.apache.hadoop.hbase.util.PoolMap
- org.apache.hadoop.hbase.util.PoolMap.Pool<R> - Interface in org.apache.hadoop.hbase.util
- org.apache.hadoop.hbase.util.PoolMap.PoolResourceSupplier<R> - Interface in org.apache.hadoop.hbase.util
- org.apache.hadoop.hbase.util.PoolMap.PoolType - Enum Class in org.apache.hadoop.hbase.util
- popArguments(Stack<ByteBuffer>, Stack<Filter>) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Pops an argument from the operator stack and the number of arguments required by the operator from the filterStack and evaluates them
- populateBalanceRSGroupResponse(RSGroupAdminProtos.BalanceRSGroupResponse.Builder, BalanceResponse) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
- populatePut(byte[], ImportTsv.TsvParser.ParsedLine, Put, int) - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
- port - Variable in class org.apache.hadoop.hbase.ipc.SimpleRpcServer
-
Deprecated.
- port - Static variable in class org.apache.hadoop.hbase.thrift.DemoClient
- port - Static variable in class org.apache.hadoop.hbase.thrift.HttpDoAsClient
- port() - Method in class org.apache.hadoop.hbase.client.example.HttpProxyExample
- PORT_CONF_KEY - Static variable in class org.apache.hadoop.hbase.thrift.Constants
- PORT_OPTION - Static variable in class org.apache.hadoop.hbase.thrift.Constants
- position - Variable in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
-
The current index into the range.
- position() - Method in class org.apache.hadoop.hbase.nio.ByteBuff
-
Returns this ByteBuff's current position
- position() - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
Returns this MBB's current position
- position() - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
- position(int) - Method in class org.apache.hadoop.hbase.nio.ByteBuff
-
Sets this ByteBuff's position to the given value.
- position(int) - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
Sets this MBB's position to the given value.
- position(int) - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
- org.apache.hadoop.hbase.util.PositionedByteRange - Interface in org.apache.hadoop.hbase.util
-
Extends
ByteRange
with additional methods to support tracking a consumers position within the viewport. - positionToByteArray(long) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
- positiveJitterRate() - Method in class org.apache.hadoop.hbase.regionserver.ConstantSizeRegionSplitPolicy
- post(String, String, byte[]) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Send a POST request
- post(String, String, byte[], Header) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Send a POST request
- post(String, Header[], byte[]) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Send a POST request
- post(Cluster, String, String, byte[]) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Send a POST request
- post(Cluster, String, String, byte[], Header) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Send a POST request
- post(Cluster, String, Header[], byte[]) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Send a POST request
- post(CellSetModel, UriInfo) - Method in class org.apache.hadoop.hbase.rest.RowResource
- post(NamespacesInstanceModel, UriInfo) - Method in class org.apache.hadoop.hbase.rest.NamespacesInstanceResource
-
Build a response for POST create namespace with properties specified.
- post(ScannerModel, UriInfo) - Method in class org.apache.hadoop.hbase.rest.ScannerResource
- post(TableSchemaModel, UriInfo) - Method in class org.apache.hadoop.hbase.rest.SchemaResource
- postAbortProcedure() - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- postAbortProcedure(ObserverContext<MasterCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after a abortProcedure request has been processed.
- postAddReplicationPeer(String, ReplicationPeerConfig) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- postAddReplicationPeer(ObserverContext<MasterCoprocessorEnvironment>, String, ReplicationPeerConfig) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after add a replication peer
- postAddRSGroup(String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- postAddRSGroup(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after a new region server group is added
- postAppend(long, long, WALKey, WALEdit) - Method in class org.apache.hadoop.hbase.regionserver.wal.MetricsWAL
- postAppend(long, long, WALKey, WALEdit) - Method in interface org.apache.hadoop.hbase.regionserver.wal.WALActionsListener
-
For notification post append to the writer.
- postAppend(Append, Result, WALEdit) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
- postAppend(ObserverContext<? extends RegionCoprocessorEnvironment>, Append, Result) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Deprecated.since 3.0.0 and will be removed in 4.0.0. Use
RegionObserver.postAppend(ObserverContext, Append, Result, WALEdit)
instead. - postAppend(ObserverContext<? extends RegionCoprocessorEnvironment>, Append, Result, WALEdit) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called after Append
- postAppendBeforeWAL(Mutation, List<Pair<Cell, Cell>>) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
- postAppendBeforeWAL(ObserverContext<? extends RegionCoprocessorEnvironment>, Mutation, List<Pair<Cell, Cell>>) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called after a list of new cells has been created during an append operation, but before they are committed to the WAL or memstore.
- postAssign(RegionInfo) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- postAssign(ObserverContext<MasterCoprocessorEnvironment>, RegionInfo) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after the region assignment has been requested.
- postBalance(BalanceRequest, List<RegionPlan>) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- postBalance(ObserverContext<MasterCoprocessorEnvironment>, BalanceRequest, List<RegionPlan>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after the balancing plan has been submitted.
- postBalanceRSGroup(String, BalanceRequest, BalanceResponse) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- postBalanceRSGroup(ObserverContext<MasterCoprocessorEnvironment>, String, BalanceRequest, BalanceResponse) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after a region server group is removed
- postBalanceSwitch(boolean, boolean) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- postBalanceSwitch(ObserverContext<MasterCoprocessorEnvironment>, boolean, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after the flag to enable/disable balancing has changed.
- postBatchMutate(ObserverContext<? extends RegionCoprocessorEnvironment>, MiniBatchOperationInProgress<Mutation>) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
This will be called after applying a batch of Mutations on a region.
- postBatchMutate(MiniBatchOperationInProgress<Mutation>) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
- postBatchMutateIndispensably(ObserverContext<? extends RegionCoprocessorEnvironment>, MiniBatchOperationInProgress<Mutation>, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called after the completion of batch put/delete/increment/append and will be called even if the batch operation fails.
- postBatchMutateIndispensably(MiniBatchOperationInProgress<Mutation>, boolean) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
- postBinary(byte[], UriInfo, HttpHeaders) - Method in class org.apache.hadoop.hbase.rest.RowResource
- postBulkLoadHFile(List<Pair<byte[], String>>, Map<byte[], List<Path>>) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
- postBulkLoadHFile(ObserverContext<? extends RegionCoprocessorEnvironment>, List<Pair<byte[], String>>, Map<byte[], List<Path>>) - Method in class org.apache.hadoop.hbase.backup.BackupObserver
- postBulkLoadHFile(ObserverContext<? extends RegionCoprocessorEnvironment>, List<Pair<byte[], String>>, Map<byte[], List<Path>>) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called after bulkLoadHFile.
- postCellEncode(int, int) - Method in class org.apache.hadoop.hbase.io.encoding.EncodingState
- postCheckAndDelete(ObserverContext<? extends RegionCoprocessorEnvironment>, byte[], byte[], byte[], CompareOperator, ByteArrayComparable, Delete, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Deprecated.since 3.0.0 and will be removed in 4.0.0. Use
RegionObserver.postCheckAndMutate(ObserverContext, CheckAndMutate, CheckAndMutateResult)
instead. - postCheckAndDelete(ObserverContext<? extends RegionCoprocessorEnvironment>, byte[], Filter, Delete, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Deprecated.since 3.0.0 and will be removed in 4.0.0. Use
RegionObserver.postCheckAndMutate(ObserverContext, CheckAndMutate, CheckAndMutateResult)
instead. - postCheckAndMutate(CheckAndMutate, CheckAndMutateResult) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
- postCheckAndMutate(ObserverContext<? extends RegionCoprocessorEnvironment>, CheckAndMutate, CheckAndMutateResult) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called after checkAndMutate
- postCheckAndPut(ObserverContext<? extends RegionCoprocessorEnvironment>, byte[], byte[], byte[], CompareOperator, ByteArrayComparable, Put, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Deprecated.since 3.0.0 and will be removed in 4.0.0. Use
RegionObserver.postCheckAndMutate(ObserverContext, CheckAndMutate, CheckAndMutateResult)
instead. - postCheckAndPut(ObserverContext<? extends RegionCoprocessorEnvironment>, byte[], Filter, Put, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Deprecated.since 3.0.0 and will be removed in 4.0.0. Use
RegionObserver.postCheckAndMutate(ObserverContext, CheckAndMutate, CheckAndMutateResult)
instead. - postClearCompactionQueues() - Method in class org.apache.hadoop.hbase.regionserver.RegionServerCoprocessorHost
- postClearCompactionQueues(ObserverContext<RegionServerCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionServerObserver
-
This will be called after clearing compaction queues
- postClearDeadServers(List<ServerName>, List<ServerName>) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- postClearDeadServers(ObserverContext<MasterCoprocessorEnvironment>, List<ServerName>, List<ServerName>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after clear dead region servers.
- postClearRegionBlockCache(CacheEvictionStats) - Method in class org.apache.hadoop.hbase.regionserver.RegionServerCoprocessorHost
- postClearRegionBlockCache(ObserverContext<RegionServerCoprocessorEnvironment>, CacheEvictionStats) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionServerObserver
-
Called after clearing the block caches for one or more regions
- postCloneSnapshot(SnapshotDescription, TableDescriptor) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- postCloneSnapshot(ObserverContext<MasterCoprocessorEnvironment>, SnapshotDescription, TableDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after a snapshot clone operation has been requested.
- postClose(boolean) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
Invoked after a region is closed
- postClose(ObserverContext<? extends RegionCoprocessorEnvironment>, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called after the region is reported as closed to the master.
- postCloseRegionOperation(ObserverContext<? extends RegionCoprocessorEnvironment>, Region.Operation) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called after releasing read lock in
Region.closeRegionOperation()
. - postCloseRegionOperation(Region.Operation) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
- postCommitStoreFile(byte[], Path, Path) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
- postCommitStoreFile(ObserverContext<? extends RegionCoprocessorEnvironment>, byte[], Path, Path) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called after moving bulk loaded hfile to region directory.
- postCompact(ObserverContext<? extends RegionCoprocessorEnvironment>, Store, StoreFile, CompactionLifeCycleTracker, CompactionRequest) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called after compaction has completed and the new store file has been moved in to place.
- postCompact(HStore, HStoreFile, CompactionLifeCycleTracker, CompactionRequest, User) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
Called after the store compaction has completed.
- postCompactSelection(ObserverContext<? extends RegionCoprocessorEnvironment>, Store, List<? extends StoreFile>, CompactionLifeCycleTracker, CompactionRequest) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called after the
StoreFile
s to compact have been selected from the available candidates. - postCompactSelection(HStore, List<HStoreFile>, CompactionLifeCycleTracker, CompactionRequest, User) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
Called after the
HStoreFile
s to be compacted have been selected from the available candidates. - postCompletedCreateTableAction(TableDescriptor, RegionInfo[], User) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- postCompletedCreateTableAction(ObserverContext<MasterCoprocessorEnvironment>, TableDescriptor, RegionInfo[]) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after the createTable operation has been requested.
- postCompletedDeleteTableAction(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after
HMaster
deletes a table. - postCompletedDeleteTableAction(TableName, User) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- postCompletedDisableTableAction(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after the disableTable operation has been requested.
- postCompletedDisableTableAction(TableName, User) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- postCompletedEnableTableAction(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after the enableTable operation has been requested.
- postCompletedEnableTableAction(TableName, User) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- postCompletedMergeRegionsAction(RegionInfo[], RegionInfo, User) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
Invoked after completing merge regions operation
- postCompletedMergeRegionsAction(ObserverContext<MasterCoprocessorEnvironment>, RegionInfo[], RegionInfo) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
called after the regions merge.
- postCompletedModifyTableAction(ObserverContext<MasterCoprocessorEnvironment>, TableName, TableDescriptor, TableDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after to modifying a table's properties.
- postCompletedModifyTableAction(TableName, TableDescriptor, TableDescriptor, User) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- postCompletedSnapshotAction(SnapshotDescription, TableDescriptor) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- postCompletedSnapshotAction(ObserverContext<MasterCoprocessorEnvironment>, SnapshotDescription, TableDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after the snapshot operation has been completed.
- postCompletedSplitRegionAction(RegionInfo, RegionInfo, User) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
Invoked just after a split
- postCompletedSplitRegionAction(ObserverContext<MasterCoprocessorEnvironment>, RegionInfo, RegionInfo) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after the region is split.
- postCompletedTruncateTableAction(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after
HMaster
truncates a table. - postCompletedTruncateTableAction(TableName, User) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- postCreateNamespace(ObserverContext<MasterCoprocessorEnvironment>, NamespaceDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after the createNamespace operation has been requested.
- postCreateNamespace(NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- postCreateReplicationEndPoint(ObserverContext<RegionServerCoprocessorEnvironment>, ReplicationEndpoint) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionServerObserver
-
This will be called after the replication endpoint is instantiated.
- postCreateReplicationEndPoint(ReplicationEndpoint) - Method in class org.apache.hadoop.hbase.regionserver.RegionServerCoprocessorHost
- postCreateTable(TableDescriptor, RegionInfo[]) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- postCreateTable(ObserverContext<MasterCoprocessorEnvironment>, TableDescriptor, RegionInfo[]) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after the createTable operation has been requested.
- postDecommissionRegionServers(List<ServerName>, boolean) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- postDecommissionRegionServers(ObserverContext<MasterCoprocessorEnvironment>, List<ServerName>, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after decommission region servers.
- postDelete(Delete, WALEdit) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
- postDelete(ObserverContext<? extends RegionCoprocessorEnvironment>, Delete, WALEdit) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called after the client deletes a value.
- postDelete(ObserverContext<? extends RegionCoprocessorEnvironment>, Delete, WALEdit, Durability) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Deprecated.since 3.0.0 and will be removed in 4.0.0. Use
RegionObserver.postDelete(ObserverContext, Delete, WALEdit)
instead. - postDeleteNamespace(String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- postDeleteNamespace(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after the deleteNamespace operation has been requested.
- postDeleteNamespace(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in class org.apache.hadoop.hbase.quotas.MasterQuotasObserver
- postDeleteSnapshot(SnapshotDescription) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- postDeleteSnapshot(ObserverContext<MasterCoprocessorEnvironment>, SnapshotDescription) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after the delete snapshot operation has been requested.
- postDeleteTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after the deleteTable operation has been requested.
- postDeleteTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.quotas.MasterQuotasObserver
- postDeleteTable(TableName) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- postDisableReplicationPeer(String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- postDisableReplicationPeer(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after disable a replication peer
- postDisableTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after the disableTable operation has been requested.
- postDisableTable(TableName) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- postEnableReplicationPeer(String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- postEnableReplicationPeer(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after enable a replication peer
- postEnableTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after the enableTable operation has been requested.
- postEnableTable(TableName) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- postEncoding(HFileBlockEncodingContext) - Method in class org.apache.hadoop.hbase.io.encoding.AbstractDataBlockEncoder
- postEncoding(BlockType) - Method in class org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultEncodingContext
- postEncoding(BlockType) - Method in interface org.apache.hadoop.hbase.io.encoding.HFileBlockEncodingContext
-
Do any action that needs to be performed after the encoding.
- postEndpointInvocation(ObserverContext<? extends RegionCoprocessorEnvironment>, Service, String, Message, Message.Builder) - Method in interface org.apache.hadoop.hbase.coprocessor.EndpointObserver
-
Called after an Endpoint service method is invoked.
- postEndpointInvocation(Service, String, Message, Message.Builder) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
- postEnvCall() - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost.ObserverOperationWithResult
- postExecuteProcedures() - Method in class org.apache.hadoop.hbase.regionserver.RegionServerCoprocessorHost
- postExecuteProcedures(ObserverContext<RegionServerCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionServerObserver
-
This will be called after executing procedures
- postExists(Get, boolean) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
- postExists(ObserverContext<? extends RegionCoprocessorEnvironment>, Get, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called after the client tests for existence using a Get.
- postFlush(ObserverContext<? extends RegionCoprocessorEnvironment>, FlushLifeCycleTracker) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called after the memstore is flushed to disk.
- postFlush(ObserverContext<? extends RegionCoprocessorEnvironment>, Store, StoreFile, FlushLifeCycleTracker) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called after a Store's memstore is flushed to disk.
- postFlush(FlushLifeCycleTracker) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
Invoked after a memstore flush
- postFlush(HStore, HStoreFile, FlushLifeCycleTracker) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
Invoked after a memstore flush
- postGet(Get, List<Cell>) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
- postGetClusterMetrics(ClusterMetrics) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- postGetClusterMetrics(ObserverContext<MasterCoprocessorEnvironment>, ClusterMetrics) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after get cluster status.
- postGetConfiguredNamespacesAndTablesInRSGroup(String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- postGetConfiguredNamespacesAndTablesInRSGroup(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after getting the configured namespaces and tables in the region server group.
- postGetLocks(List<LockedResource>) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- postGetLocks(ObserverContext<MasterCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after a getLocks request has been processed.
- postGetNamespaceDescriptor(ObserverContext<MasterCoprocessorEnvironment>, NamespaceDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after a getNamespaceDescriptor request has been processed.
- postGetNamespaceDescriptor(NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- postGetOp(ObserverContext<? extends RegionCoprocessorEnvironment>, Get, List<Cell>) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called after the client performs a Get
- postGetProcedures(List<Procedure<?>>) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- postGetProcedures(ObserverContext<MasterCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after a getProcedures request has been processed.
- postGetReplicationPeerConfig(String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- postGetReplicationPeerConfig(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after get the configured ReplicationPeerConfig for the specified peer
- postGetRSGroupInfo(String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- postGetRSGroupInfo(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after getting region server group info of the passed groupName.
- postGetRSGroupInfoOfServer(ObserverContext<MasterCoprocessorEnvironment>, Address) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after getting region server group info of the passed server.
- postGetRSGroupInfoOfServer(Address) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- postGetRSGroupInfoOfTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after getting region server group info of the passed tableName.
- postGetRSGroupInfoOfTable(TableName) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- postGetTableDescriptors(List<TableName>, List<TableDescriptor>, String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- postGetTableDescriptors(ObserverContext<MasterCoprocessorEnvironment>, List<TableName>, List<TableDescriptor>, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after a getTableDescriptors request has been processed.
- postGetTableNames(List<TableDescriptor>, String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- postGetTableNames(ObserverContext<MasterCoprocessorEnvironment>, List<TableDescriptor>, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after a getTableNames request has been processed.
- postGetUserPermissions(String, String, TableName, byte[], byte[]) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- postGetUserPermissions(ObserverContext<MasterCoprocessorEnvironment>, String, String, TableName, byte[], byte[]) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after getting user permissions.
- postGrant(ObserverContext<MasterCoprocessorEnvironment>, UserPermission, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after granting user permissions.
- postGrant(UserPermission, boolean) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- postHasUserPermissions(String, List<Permission>) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- postHasUserPermissions(ObserverContext<MasterCoprocessorEnvironment>, String, List<Permission>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after checking if user has permissions.
- postIncrement(Increment, Result, WALEdit) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
- postIncrement(ObserverContext<? extends RegionCoprocessorEnvironment>, Increment, Result) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Deprecated.since 3.0.0 and will be removed in 4.0.0. Use
RegionObserver.postIncrement(ObserverContext, Increment, Result, WALEdit)
instead. - postIncrement(ObserverContext<? extends RegionCoprocessorEnvironment>, Increment, Result, WALEdit) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called after increment
- postIncrementBeforeWAL(Mutation, List<Pair<Cell, Cell>>) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
- postIncrementBeforeWAL(ObserverContext<? extends RegionCoprocessorEnvironment>, Mutation, List<Pair<Cell, Cell>>) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called after a list of new cells has been created during an increment operation, but before they are committed to the WAL or memstore.
- postInstantiateDeleteTracker(ObserverContext<? extends RegionCoprocessorEnvironment>, DeleteTracker) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Deprecated.Since 2.0.0, will be removed in 4.0.0. Visibility label feature still use this method, so it can not be removed in 3.0.0
- postInstantiateDeleteTracker(DeleteTracker) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
- postIsRpcThrottleEnabled(boolean) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- postIsRpcThrottleEnabled(ObserverContext<MasterCoprocessorEnvironment>, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after getting if is rpc throttle enabled.
- postListDecommissionedRegionServers() - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- postListDecommissionedRegionServers(ObserverContext<MasterCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after list decommissioned region servers.
- postListNamespaceDescriptors(List<NamespaceDescriptor>) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- postListNamespaceDescriptors(ObserverContext<MasterCoprocessorEnvironment>, List<NamespaceDescriptor>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after a listNamespaceDescriptors request has been processed.
- postListNamespaces(List<String>) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- postListNamespaces(ObserverContext<MasterCoprocessorEnvironment>, List<String>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after a listNamespaces request has been processed.
- postListReplicationPeers(String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- postListReplicationPeers(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after list replication peers.
- postListRSGroups() - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- postListRSGroups(ObserverContext<MasterCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after listing region server group information.
- postListSnapshot(SnapshotDescription) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- postListSnapshot(ObserverContext<MasterCoprocessorEnvironment>, SnapshotDescription) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after listSnapshots request has been processed.
- postListTablesInRSGroup(String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- postListTablesInRSGroup(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after listing all tables in the region server group.
- postLockHeartbeat(ObserverContext<MasterCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after heartbeat to a lock.
- postLockHeartbeat(LockProcedure, boolean) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- postLogArchive(Path, Path) - Method in interface org.apache.hadoop.hbase.regionserver.wal.WALActionsListener
-
The WAL has been archived.
- postLogRoll(Path, Path) - Method in class org.apache.hadoop.hbase.regionserver.wal.MetricsWAL
- postLogRoll(Path, Path) - Method in interface org.apache.hadoop.hbase.regionserver.wal.WALActionsListener
-
The WAL has been rolled.
- postLogRoll(Path, Path) - Method in class org.apache.hadoop.hbase.regionserver.wal.WALEventTrackerListener
- postMasterStartupInitialize() - Method in interface org.apache.hadoop.hbase.master.LoadBalancer
-
If balancer needs to do initialization after Master has started up, lets do that here.
- postMasterStartupInitialize() - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupBasedLoadBalancer
- postMasterStoreFlush() - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- postMasterStoreFlush(ObserverContext<MasterCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after the master local region memstore is flushed to disk.
- postMemStoreCompaction(ObserverContext<? extends RegionCoprocessorEnvironment>, Store) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called after the in memory compaction is finished.
- postMemStoreCompaction(HStore) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
Invoked after in memory compaction.
- postMergeRegions(RegionInfo[]) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- postMergeRegions(ObserverContext<MasterCoprocessorEnvironment>, RegionInfo[]) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
called after merge regions request.
- postMergeRegionsCommit(RegionInfo[], RegionInfo, User) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
Invoked after merge regions operation writes the new region to hbase:meta
- postMergeRegionsCommitAction(ObserverContext<MasterCoprocessorEnvironment>, RegionInfo[], RegionInfo) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
This will be called after META step as part of regions merge transaction.
- postModifyColumnFamilyStoreFileTracker(ObserverContext<MasterCoprocessorEnvironment>, TableName, byte[], String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after modifying a family store file tracker.
- postModifyColumnFamilyStoreFileTracker(TableName, byte[], String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- postModifyNamespace(ObserverContext<MasterCoprocessorEnvironment>, NamespaceDescriptor, NamespaceDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after the modifyNamespace operation has been requested.
- postModifyNamespace(NamespaceDescriptor, NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- postModifyTable(ObserverContext<MasterCoprocessorEnvironment>, TableName, TableDescriptor, TableDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after the modifyTable operation has been requested.
- postModifyTable(TableName, TableDescriptor, TableDescriptor) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- postModifyTableStoreFileTracker(ObserverContext<MasterCoprocessorEnvironment>, TableName, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after modifying a table's store file tracker.
- postModifyTableStoreFileTracker(TableName, String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- postMove(RegionInfo, ServerName, ServerName) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- postMove(ObserverContext<MasterCoprocessorEnvironment>, RegionInfo, ServerName, ServerName) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after the region move has been requested.
- postMoveServers(Set<Address>, String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- postMoveServers(ObserverContext<MasterCoprocessorEnvironment>, Set<Address>, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after servers are moved to target region server group
- postMoveServersAndTables(Set<Address>, Set<TableName>, String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- postMoveServersAndTables(ObserverContext<MasterCoprocessorEnvironment>, Set<Address>, Set<TableName>, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after servers are moved to target region server group
- postMoveTables(Set<TableName>, String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- postMoveTables(ObserverContext<MasterCoprocessorEnvironment>, Set<TableName>, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after servers are moved to target region server group
- postMutationBeforeWAL(ObserverContext<? extends RegionCoprocessorEnvironment>, RegionObserver.MutationType, Mutation, Cell, Cell) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Deprecated.since 2.2.0 and will be removedin 4.0.0. Use
RegionObserver.postIncrementBeforeWAL(ObserverContext, Mutation, List)
orRegionObserver.postAppendBeforeWAL(ObserverContext, Mutation, List)
instead. - postOpen() - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
Invoked after a region open
- postOpen(ObserverContext<? extends RegionCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called after the region is reported as open to the master.
- PostOpenDeployContext(HRegion, long, long, long) - Constructor for class org.apache.hadoop.hbase.regionserver.RegionServerServices.PostOpenDeployContext
- postOpenDeployTasks(RegionServerServices.PostOpenDeployContext) - Method in class org.apache.hadoop.hbase.MockRegionServerServices
- postOpenDeployTasks(RegionServerServices.PostOpenDeployContext) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
- postOpenDeployTasks(RegionServerServices.PostOpenDeployContext) - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
Tasks to perform after region open to complete deploy of region on regionserver
- postPut(Put, WALEdit) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
- postPut(ObserverContext<? extends RegionCoprocessorEnvironment>, Put, WALEdit) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called after the client stores a value.
- postPut(ObserverContext<? extends RegionCoprocessorEnvironment>, Put, WALEdit, Durability) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Deprecated.since 3.0.0 and will be removed in 4.0.0. Use
RegionObserver.postPut(ObserverContext, Put, WALEdit)
instead. - postRecommissionRegionServer(ObserverContext<MasterCoprocessorEnvironment>, ServerName, List<byte[]>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after recommission region server.
- postRecommissionRegionServer(ServerName, List<byte[]>) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- postRegionOffline(RegionInfo) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- postRegionOffline(ObserverContext<MasterCoprocessorEnvironment>, RegionInfo) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after the region has been marked offline.
- postRemoveReplicationPeer(String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- postRemoveReplicationPeer(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after remove a replication peer
- postRemoveRSGroup(String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- postRemoveRSGroup(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after a region server group is removed
- postRemoveServers(Set<Address>) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- postRemoveServers(ObserverContext<MasterCoprocessorEnvironment>, Set<Address>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after servers are removed from rsgroup
- postRenameRSGroup(String, String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- postRenameRSGroup(ObserverContext<MasterCoprocessorEnvironment>, String, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after rename rsgroup.
- postReplayWALs(RegionInfo, Path) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
- postReplayWALs(ObserverContext<? extends RegionCoprocessorEnvironment>, RegionInfo, Path) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called after replaying WALs for this region.
- postReplicateLogEntries() - Method in class org.apache.hadoop.hbase.regionserver.RegionServerCoprocessorHost
- postReplicateLogEntries(ObserverContext<RegionServerCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionServerObserver
-
Deprecated.As of release 2.0.0 with out any replacement, plan to remove in 4.0.0. This is maintained for internal usage by AccessController. Do not use these hooks in custom co-processors.
- postReplicationSinkBatchMutate(ObserverContext<RegionServerCoprocessorEnvironment>, AdminProtos.WALEntry, Mutation) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionServerObserver
-
This will be called after replication sink mutations are executed on the sink table as part of batch call.
- postReplicationSinkBatchMutate(AdminProtos.WALEntry, Mutation) - Method in class org.apache.hadoop.hbase.regionserver.RegionServerCoprocessorHost
- postRequestLock(String, TableName, RegionInfo[], LockType, String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- postRequestLock(ObserverContext<MasterCoprocessorEnvironment>, String, TableName, RegionInfo[], String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after new LockProcedure is queued.
- postRestoreSnapshot(SnapshotDescription, TableDescriptor) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- postRestoreSnapshot(ObserverContext<MasterCoprocessorEnvironment>, SnapshotDescription, TableDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after a snapshot restore operation has been requested.
- postRevoke(ObserverContext<MasterCoprocessorEnvironment>, UserPermission) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after revoking user permissions.
- postRevoke(UserPermission) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- postRollBackMergeRegionsAction(RegionInfo[], User) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
Invoked after rollback merge regions operation
- postRollBackMergeRegionsAction(ObserverContext<MasterCoprocessorEnvironment>, RegionInfo[]) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
This will be called after the roll back of the regions merge.
- postRollBackSplitRegionAction(ObserverContext<MasterCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
This will be called after the roll back of the split region is completed
- postRollBackSplitRegionAction(User) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
Invoked just after the rollback of a failed split
- postRollWALWriterRequest() - Method in class org.apache.hadoop.hbase.regionserver.RegionServerCoprocessorHost
- postRollWALWriterRequest(ObserverContext<RegionServerCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionServerObserver
-
This will be called after executing user request to roll a region server WAL.
- postScannerClose(ObserverContext<? extends RegionCoprocessorEnvironment>, InternalScanner) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called after the client closes a scanner.
- postScannerClose(InternalScanner) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
- postScannerFilterRow(ObserverContext<? extends RegionCoprocessorEnvironment>, InternalScanner, Cell, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
This will be called by the scan flow when the current scanned row is being filtered out by the filter.
- postScannerFilterRow(InternalScanner, Cell) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
This will be called by the scan flow when the current scanned row is being filtered out by the filter.
- postScannerNext(ObserverContext<? extends RegionCoprocessorEnvironment>, InternalScanner, List<Result>, int, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called after the client asks for the next row on a scanner.
- postScannerNext(InternalScanner, List<Result>, int, boolean) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
- postScannerOpen(Scan, RegionScanner) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
- postScannerOpen(ObserverContext<? extends RegionCoprocessorEnvironment>, Scan, RegionScanner) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called after the client opens a new scanner.
- postSetNamespaceQuota(String, GlobalQuotaSettings) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- postSetNamespaceQuota(ObserverContext<MasterCoprocessorEnvironment>, String, GlobalQuotaSettings) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after the quota for the namespace is stored.
- postSetRegionServerQuota(String, GlobalQuotaSettings) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- postSetRegionServerQuota(ObserverContext<MasterCoprocessorEnvironment>, String, GlobalQuotaSettings) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after the quota for the region server is stored.
- postSetSplitOrMergeEnabled(boolean, MasterSwitchType) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- postSetSplitOrMergeEnabled(ObserverContext<MasterCoprocessorEnvironment>, boolean, MasterSwitchType) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after setting split / merge switch
- postSetTableQuota(ObserverContext<MasterCoprocessorEnvironment>, TableName, GlobalQuotaSettings) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after the quota for the table is stored.
- postSetTableQuota(TableName, GlobalQuotaSettings) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- postSetUserQuota(String, String, GlobalQuotaSettings) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- postSetUserQuota(String, GlobalQuotaSettings) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- postSetUserQuota(String, TableName, GlobalQuotaSettings) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- postSetUserQuota(ObserverContext<MasterCoprocessorEnvironment>, String, String, GlobalQuotaSettings) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after the quota for the user on the specified namespace is stored.
- postSetUserQuota(ObserverContext<MasterCoprocessorEnvironment>, String, GlobalQuotaSettings) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after the quota for the user is stored.
- postSetUserQuota(ObserverContext<MasterCoprocessorEnvironment>, String, TableName, GlobalQuotaSettings) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after the quota for the user on the specified table is stored.
- postSnapshot(SnapshotDescription, TableDescriptor, User) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- postSnapshot(ObserverContext<MasterCoprocessorEnvironment>, SnapshotDescription, TableDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after the snapshot operation has been requested.
- postSnapshotOperation() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
Perform tasks needed after the completion of snapshot operation.
- postStart() - Method in class org.apache.hadoop.hbase.zookeeper.MasterAddressTracker
- postStart() - Method in class org.apache.hadoop.hbase.zookeeper.ZKNodeTracker
-
Called after start is called.
- postStartMaster() - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- postStartMaster(ObserverContext<MasterCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called immediately after an active master instance has completed initialization.
- postStartRegionOperation(ObserverContext<? extends RegionCoprocessorEnvironment>, Region.Operation) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
This will be called for region operations where read lock is acquired in
Region.startRegionOperation()
. - postStartRegionOperation(Region.Operation) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
- postStoreFileReaderOpen(FileSystem, Path, FSDataInputStreamWrapper, long, CacheConfig, Reference, StoreFileReader) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
- postStoreFileReaderOpen(ObserverContext<? extends RegionCoprocessorEnvironment>, FileSystem, Path, FSDataInputStreamWrapper, long, CacheConfig, Reference, StoreFileReader) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Deprecated.For Phoenix only, StoreFileReader is not a stable interface.
- postSwitchExceedThrottleQuota(boolean, boolean) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- postSwitchExceedThrottleQuota(ObserverContext<MasterCoprocessorEnvironment>, boolean, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after switching exceed throttle quota state.
- postSwitchRpcThrottle(boolean, boolean) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- postSwitchRpcThrottle(ObserverContext<MasterCoprocessorEnvironment>, boolean, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after switching rpc throttle enabled state.
- postSync(long, int) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
- postSync(long, int) - Method in class org.apache.hadoop.hbase.regionserver.wal.MetricsWAL
- postSync(long, int) - Method in interface org.apache.hadoop.hbase.regionserver.wal.WALActionsListener
-
For notification post writer sync.
- postTableFlush(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after the table memstore is flushed to disk.
- postTableFlush(TableName) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- postTransitReplicationPeerSyncReplicationState(String, SyncReplicationState, SyncReplicationState) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- postTransitReplicationPeerSyncReplicationState(ObserverContext<MasterCoprocessorEnvironment>, String, SyncReplicationState, SyncReplicationState) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after transit current cluster state for the specified synchronous replication peer
- postTruncateRegion(RegionInfo) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
Invoked after calling the truncate region procedure
- postTruncateRegion(ObserverContext<MasterCoprocessorEnvironment>, RegionInfo) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after the truncate region procedure is called.
- postTruncateRegionAction(RegionInfo, User) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
Invoked after calling the truncate region procedure
- postTruncateRegionAction(ObserverContext<MasterCoprocessorEnvironment>, RegionInfo) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called post the region is truncated.
- postTruncateTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after the truncateTable operation has been requested.
- postTruncateTable(TableName) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- postUnassign(RegionInfo) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- postUnassign(ObserverContext<MasterCoprocessorEnvironment>, RegionInfo) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after the region unassignment has been requested.
- postUpdate(MutableSegment) - Method in class org.apache.hadoop.hbase.regionserver.AbstractMemStore
-
Issue any post update synchronization and tests
- postUpdate(MutableSegment) - Method in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
- postUpdate(MutableSegment) - Method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore
- postUpdateConfiguration(Configuration) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- postUpdateConfiguration(Configuration) - Method in class org.apache.hadoop.hbase.regionserver.RegionServerCoprocessorHost
- postUpdateMasterConfiguration(ObserverContext<MasterCoprocessorEnvironment>, Configuration) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after reloading the HMaster's
Configuration
from disk - postUpdateRegionServerConfiguration(ObserverContext<RegionServerCoprocessorEnvironment>, Configuration) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionServerObserver
-
Called after reloading the RegionServer's
Configuration
from disk - postUpdateReplicationPeerConfig(String, ReplicationPeerConfig) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- postUpdateReplicationPeerConfig(ObserverContext<MasterCoprocessorEnvironment>, String, ReplicationPeerConfig) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after update peerConfig for the specified peer
- postUpdateRSGroupConfig(String, Map<String, String>) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- postUpdateRSGroupConfig(ObserverContext<MasterCoprocessorEnvironment>, String, Map<String, String>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after update rsgroup config.
- postWALRoll(Path, Path) - Method in class org.apache.hadoop.hbase.regionserver.wal.WALCoprocessorHost
-
Called after rolling the current WAL
- postWALRoll(ObserverContext<? extends WALCoprocessorEnvironment>, Path, Path) - Method in interface org.apache.hadoop.hbase.coprocessor.WALObserver
-
Called after rolling the current WAL
- postWALWrite(RegionInfo, WALKey, WALEdit) - Method in class org.apache.hadoop.hbase.regionserver.wal.WALCoprocessorHost
- postWALWrite(ObserverContext<? extends WALCoprocessorEnvironment>, RegionInfo, WALKey, WALEdit) - Method in interface org.apache.hadoop.hbase.coprocessor.WALObserver
-
Called after a
WALEdit
is writen to WAL. - preAbortProcedure(ObserverContext<MasterCoprocessorEnvironment>, long) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before a abortProcedure request has been processed.
- preAbortProcedure(ProcedureExecutor<MasterProcedureEnv>, long) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- pread - Variable in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
- PREAD - Enum constant in enum class org.apache.hadoop.hbase.client.Scan.ReadType
- PREAD - Enum constant in enum class org.apache.hadoop.hbase.io.hfile.ReaderContext.ReaderType
- preAddReplicationPeer(String, ReplicationPeerConfig) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- preAddReplicationPeer(ObserverContext<MasterCoprocessorEnvironment>, String, ReplicationPeerConfig) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before add a replication peer
- preAddRSGroup(String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- preAddRSGroup(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before a new region server group is added
- preadWithExtra(ByteBuff, FSDataInputStream, long, int, int) - Static method in class org.apache.hadoop.hbase.io.util.BlockIOUtils
-
Read from an input stream at least
necessaryLen
and if possible,extraLen
also if available. - preadWithExtra(ByteBuff, FSDataInputStream, long, int, int, boolean) - Static method in class org.apache.hadoop.hbase.io.util.BlockIOUtils
-
Read from an input stream at least
necessaryLen
and if possible,extraLen
also if available. - preAppend(Append, WALEdit) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
Supports Coprocessor 'bypass'.
- preAppend(ObserverContext<? extends RegionCoprocessorEnvironment>, Append) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Deprecated.since 3.0.0 and will be removed in 4.0.0. Use
RegionObserver.preAppend(ObserverContext, Append, WALEdit)
instead. - preAppend(ObserverContext<? extends RegionCoprocessorEnvironment>, Append, WALEdit) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called before Append.
- preAppendAfterRowLock(Append) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
Supports Coprocessor 'bypass'.
- preAppendAfterRowLock(ObserverContext<? extends RegionCoprocessorEnvironment>, Append) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Deprecated.since 3.0.0 and will be removed in 4.0.0. Use
RegionObserver.preBatchMutate(ObserverContext, MiniBatchOperationInProgress)
instead. - preAssign(RegionInfo) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- preAssign(ObserverContext<MasterCoprocessorEnvironment>, RegionInfo) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called prior to assigning a specific region.
- preBalance(BalanceRequest) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- preBalance(ObserverContext<MasterCoprocessorEnvironment>, BalanceRequest) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called prior to requesting rebalancing of the cluster regions, though after the initial checks for regions in transition and the balance switch flag.
- preBalanceRSGroup(String, BalanceRequest) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- preBalanceRSGroup(ObserverContext<MasterCoprocessorEnvironment>, String, BalanceRequest) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before a region server group is removed
- preBalanceSwitch(boolean) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- preBalanceSwitch(ObserverContext<MasterCoprocessorEnvironment>, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called prior to modifying the flag used to enable/disable region balancing.
- preBatchMutate(ObserverContext<? extends RegionCoprocessorEnvironment>, MiniBatchOperationInProgress<Mutation>) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
This will be called for every batch mutation operation happening at the server.
- preBatchMutate(MiniBatchOperationInProgress<Mutation>) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
- preBulkLoadHFile(String, long) - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
This method should only be called from Region.
- preBulkLoadHFile(List<Pair<byte[], String>>) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
- preBulkLoadHFile(ObserverContext<? extends RegionCoprocessorEnvironment>, List<Pair<byte[], String>>) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called before bulkLoadHFile.
- preCheck(TableDescriptor) - Method in class org.apache.hadoop.hbase.regionserver.storefiletracker.ModifyColumnFamilyStoreFileTrackerProcedure
- preCheck(TableDescriptor) - Method in class org.apache.hadoop.hbase.regionserver.storefiletracker.ModifyStoreFileTrackerProcedure
- preCheck(TableDescriptor) - Method in class org.apache.hadoop.hbase.regionserver.storefiletracker.ModifyTableStoreFileTrackerProcedure
- preCheck(ExtendedCell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher
-
Check before the delete logic.
- preCheckAndDelete(ObserverContext<? extends RegionCoprocessorEnvironment>, byte[], byte[], byte[], CompareOperator, ByteArrayComparable, Delete, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Deprecated.since 3.0.0 and will be removed in 4.0.0. Use
RegionObserver.preCheckAndMutate(ObserverContext, CheckAndMutate, CheckAndMutateResult)
instead. - preCheckAndDelete(ObserverContext<? extends RegionCoprocessorEnvironment>, byte[], Filter, Delete, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Deprecated.since 3.0.0 and will be removed in 4.0.0. Use
RegionObserver.preCheckAndMutate(ObserverContext, CheckAndMutate, CheckAndMutateResult)
instead. - preCheckAndDeleteAfterRowLock(ObserverContext<? extends RegionCoprocessorEnvironment>, byte[], byte[], byte[], CompareOperator, ByteArrayComparable, Delete, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Deprecated.since 3.0.0 and will be removed in 4.0.0. Use
RegionObserver.preCheckAndMutateAfterRowLock(ObserverContext, CheckAndMutate,CheckAndMutateResult)
instead. - preCheckAndDeleteAfterRowLock(ObserverContext<? extends RegionCoprocessorEnvironment>, byte[], Filter, Delete, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Deprecated.since 3.0.0 and will be removed in 4.0.0. Use
RegionObserver.preCheckAndMutateAfterRowLock(ObserverContext, CheckAndMutate,CheckAndMutateResult)
instead. - preCheckAndMutate(CheckAndMutate) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
Supports Coprocessor 'bypass'.
- preCheckAndMutate(ObserverContext<? extends RegionCoprocessorEnvironment>, CheckAndMutate, CheckAndMutateResult) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called before checkAndMutate
- preCheckAndMutateAfterRowLock(CheckAndMutate) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
Supports Coprocessor 'bypass'.
- preCheckAndMutateAfterRowLock(ObserverContext<? extends RegionCoprocessorEnvironment>, CheckAndMutate, CheckAndMutateResult) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called before checkAndDelete but after acquiring rowlock.
- preCheckAndPut(ObserverContext<? extends RegionCoprocessorEnvironment>, byte[], byte[], byte[], CompareOperator, ByteArrayComparable, Put, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Deprecated.since 3.0.0 and will be removed in 4.0.0. Use
RegionObserver.preCheckAndMutate(ObserverContext, CheckAndMutate, CheckAndMutateResult)
instead. - preCheckAndPut(ObserverContext<? extends RegionCoprocessorEnvironment>, byte[], Filter, Put, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Deprecated.since 3.0.0 and will be removed in 4.0.0. Use
RegionObserver.preCheckAndMutate(ObserverContext, CheckAndMutate, CheckAndMutateResult)
instead. - preCheckAndPutAfterRowLock(ObserverContext<? extends RegionCoprocessorEnvironment>, byte[], byte[], byte[], CompareOperator, ByteArrayComparable, Put, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Deprecated.since 3.0.0 and will be removed in 4.0.0. Use
RegionObserver.preCheckAndMutateAfterRowLock(ObserverContext, CheckAndMutate,CheckAndMutateResult)
instead. - preCheckAndPutAfterRowLock(ObserverContext<? extends RegionCoprocessorEnvironment>, byte[], Filter, Put, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Deprecated.since 3.0.0 and will be removed in 4.0.0. Use
RegionObserver.preCheckAndMutateAfterRowLock(ObserverContext, CheckAndMutate,CheckAndMutateResult)
instead. - preCleanupBulkLoad(ObserverContext<RegionCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.BulkLoadObserver
-
Called as part of SecureBulkLoadEndpoint.cleanupBulkLoad() RPC call.
- preCleanupBulkLoad(User) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
- preClearCompactionQueues() - Method in class org.apache.hadoop.hbase.regionserver.RegionServerCoprocessorHost
- preClearCompactionQueues(ObserverContext<RegionServerCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionServerObserver
-
This will be called before clearing compaction queues
- preClearDeadServers() - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- preClearDeadServers(ObserverContext<MasterCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before clear dead region servers.
- preClearRegionBlockCache() - Method in class org.apache.hadoop.hbase.regionserver.RegionServerCoprocessorHost
- preClearRegionBlockCache(ObserverContext<RegionServerCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionServerObserver
-
Called before clearing the block caches for one or more regions
- preCloneSnapshot(SnapshotDescription, TableDescriptor) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- preCloneSnapshot(ObserverContext<MasterCoprocessorEnvironment>, SnapshotDescription, TableDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before a snapshot is cloned.
- preClose(boolean) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
Invoked before a region is closed
- preClose(ObserverContext<? extends RegionCoprocessorEnvironment>, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called before the region is reported as closed to the master.
- preCloseWriter(StoreFileWriter) - Method in class org.apache.hadoop.hbase.regionserver.AbstractMultiFileWriter
-
Subclasses override this method to be called before we close the give writer.
- preCloseWriter(StoreFileWriter) - Method in class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter
- preCommitStoreFile(byte[], List<Pair<Path, Path>>) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
- preCommitStoreFile(ObserverContext<? extends RegionCoprocessorEnvironment>, byte[], List<Pair<Path, Path>>) - Method in class org.apache.hadoop.hbase.backup.BackupObserver
- preCommitStoreFile(ObserverContext<? extends RegionCoprocessorEnvironment>, byte[], List<Pair<Path, Path>>) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called before moving bulk loaded hfile to region directory.
- preCommitWriters() - Method in class org.apache.hadoop.hbase.regionserver.AbstractMultiFileWriter
-
Subclasses override this method to be called at the end of a successful sequence of append; all appends are processed before this method is called.
- preCommitWriters() - Method in class org.apache.hadoop.hbase.regionserver.DateTieredMultiFileWriter
- preCommitWriters() - Method in class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter
- preCommitWritersInternal() - Method in class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter.BoundaryMultiWriter
- preCommitWritersInternal() - Method in class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter
- preCommitWritersInternal() - Method in class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter.SizeMultiWriter
- preCompact(ObserverContext<? extends RegionCoprocessorEnvironment>, Store, InternalScanner, ScanType, CompactionLifeCycleTracker, CompactionRequest) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called prior to writing the
StoreFile
s selected for compaction into a newStoreFile
. - preCompact(HStore, InternalScanner, ScanType, CompactionLifeCycleTracker, CompactionRequest, User) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
Called prior to rewriting the store files selected for compaction
- preCompactScannerOpen(ObserverContext<? extends RegionCoprocessorEnvironment>, Store, ScanType, ScanOptions, CompactionLifeCycleTracker, CompactionRequest) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called before we open store scanner for compaction.
- preCompactScannerOpen(HStore, ScanType, CompactionLifeCycleTracker, CompactionRequest, User) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
Called prior to opening store scanner for compaction.
- preCompactSelection(ObserverContext<? extends RegionCoprocessorEnvironment>, Store, List<? extends StoreFile>, CompactionLifeCycleTracker) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called prior to selecting the
StoreFiles
to compact from the list of available candidates. - preCompactSelection(HStore, List<HStoreFile>, CompactionLifeCycleTracker, User) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
Called prior to selecting the
HStoreFile
s for compaction from the list of currently available candidates. - preCreateNamespace(ObserverContext<MasterCoprocessorEnvironment>, NamespaceDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before a new namespace is created by
HMaster
. - preCreateNamespace(NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- preCreateTable(TableDescriptor, RegionInfo[]) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- preCreateTable(ObserverContext<MasterCoprocessorEnvironment>, TableDescriptor, RegionInfo[]) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before a new table is created by
HMaster
. - preCreateTableAction(TableDescriptor, RegionInfo[], User) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- preCreateTableAction(ObserverContext<MasterCoprocessorEnvironment>, TableDescriptor, RegionInfo[]) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before a new table is created by
HMaster
. - preCreateTableRegionsInfos(TableDescriptor) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- preCreateTableRegionsInfos(ObserverContext<MasterCoprocessorEnvironment>, TableDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before we create the region infos for this table.
- preDecommissionRegionServers(List<ServerName>, boolean) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- preDecommissionRegionServers(ObserverContext<MasterCoprocessorEnvironment>, List<ServerName>, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before decommission region servers.
- preDelete(Delete, WALEdit) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
Supports Coprocessor 'bypass'.
- preDelete(ObserverContext<? extends RegionCoprocessorEnvironment>, Delete, WALEdit) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called before the client deletes a value.
- preDelete(ObserverContext<? extends RegionCoprocessorEnvironment>, Delete, WALEdit, Durability) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Deprecated.since 3.0.0 and will be removed in 4.0.0. Use
RegionObserver.preDelete(ObserverContext, Delete, WALEdit)
instead. - preDeleteNamespace(String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- preDeleteNamespace(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before
HMaster
deletes a namespace - preDeleteSnapshot(SnapshotDescription) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- preDeleteSnapshot(ObserverContext<MasterCoprocessorEnvironment>, SnapshotDescription) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before a snapshot is deleted.
- preDeleteTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before
HMaster
deletes a table. - preDeleteTable(TableName) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- preDeleteTableAction(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before
HMaster
deletes a table. - preDeleteTableAction(TableName, User) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- predicateNoRegionsInTransition() - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Returns a
Predicate
for checking that there are no regions in transition in master - predicateTableAvailable(TableName) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Returns a
Predicate
for checking that table is enabled - predicateTableDisabled(TableName) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Returns a
Predicate
for checking that table is enabled - predicateTableEnabled(TableName) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Returns a
Predicate
for checking that table is enabled - preDisableReplicationPeer(String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- preDisableReplicationPeer(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before disable a replication peer
- preDisableTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called prior to disabling a table.
- preDisableTable(TableName) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- preDisableTableAction(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called prior to disabling a table.
- preDisableTableAction(TableName, User) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- PREEMPTED - Enum constant in enum class org.apache.hadoop.hbase.regionserver.SplitLogWorker.TaskExecutor.Status
-
Deprecated.
- org.apache.hadoop.hbase.exceptions.PreemptiveFastFailException - Exception in org.apache.hadoop.hbase.exceptions
-
Deprecated.since 2.3.0, and will be removed in 4.0.0.
- PreemptiveFastFailException(long, long, long, ServerName) - Constructor for exception org.apache.hadoop.hbase.exceptions.PreemptiveFastFailException
-
Deprecated.
- PreemptiveFastFailException(long, long, long, ServerName, boolean) - Constructor for exception org.apache.hadoop.hbase.exceptions.PreemptiveFastFailException
-
Deprecated.
- preEnableReplicationPeer(String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- preEnableReplicationPeer(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before enable a replication peer
- preEnableTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called prior to enabling a table.
- preEnableTable(TableName) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- preEnableTableAction(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called prior to enabling a table.
- preEnableTableAction(TableName, User) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- preEndpointInvocation(ObserverContext<? extends RegionCoprocessorEnvironment>, Service, String, Message) - Method in interface org.apache.hadoop.hbase.coprocessor.EndpointObserver
-
Called before an Endpoint service method is invoked.
- preEndpointInvocation(Service, String, Message) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
- preExecuteProcedures() - Method in class org.apache.hadoop.hbase.regionserver.RegionServerCoprocessorHost
- preExecuteProcedures(ObserverContext<RegionServerCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionServerObserver
-
This will be called before executing procedures
- preExists(Get) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
Supports Coprocessor 'bypass'.
- preExists(ObserverContext<? extends RegionCoprocessorEnvironment>, Get, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called before the client tests for existence using a Get.
- PREFETCH_BLOCKS_ON_OPEN - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
Key for the PREFETCH_BLOCKS_ON_OPEN attribute.
- PREFETCH_BLOCKS_ON_OPEN_KEY - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
Configuration key to prefetch all blocks of a given file into the block cache when the file is opened.
- PREFETCH_DELAY - Static variable in class org.apache.hadoop.hbase.io.hfile.PrefetchExecutor
-
Wait time in miliseconds before executing prefetch
- PREFETCH_DELAY - Static variable in class org.apache.hadoop.hbase.regionserver.PrefetchExecutorNotifier
-
Wait time in miliseconds before executing prefetch
- PREFETCH_DELAY_VARIATION - Static variable in class org.apache.hadoop.hbase.io.hfile.PrefetchExecutor
- PREFETCH_DELAY_VARIATION_DEFAULT_VALUE - Static variable in class org.apache.hadoop.hbase.io.hfile.PrefetchExecutor
- PREFETCH_HEAP_USAGE_THRESHOLD - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
Configuration key to set the heap usage threshold limit once prefetch threads should be interrupted.
- prefetchComplete() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
- prefetchComplete() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
-
Returns false if block prefetching was requested for this file and has not completed, true otherwise
- org.apache.hadoop.hbase.io.hfile.PrefetchExecutor - Class in org.apache.hadoop.hbase.io.hfile
- org.apache.hadoop.hbase.regionserver.PrefetchExecutorNotifier - Class in org.apache.hadoop.hbase.regionserver
-
Class to submit requests for PrefetchExecutor depending on configuration change
- PrefetchExecutorNotifier(Configuration) - Constructor for class org.apache.hadoop.hbase.regionserver.PrefetchExecutorNotifier
- prefetchStarted() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
- prefetchStarted() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
-
Returns true if block prefetching was started after waiting for specified delay, false otherwise
- prefix - Variable in class org.apache.hadoop.hbase.filter.ColumnPrefixFilter
- prefix - Variable in class org.apache.hadoop.hbase.filter.PrefixFilter
- prefix(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZKWatcher
-
Adds this instance's identifier as a prefix to the passed
str
- PREFIX - Enum constant in enum class org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
- PREFIX_LENGTH_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.KeyPrefixRegionSplitPolicy
-
Deprecated.
- PREFIX_LENGTH_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.KeyPrefixRegionSplitRestriction
- PREFIX_LENGTH_KEY - Static variable in class org.apache.hadoop.hbase.util.BloomFilterUtil
- PREFIX_LENGTH_KEY_DEPRECATED - Static variable in class org.apache.hadoop.hbase.regionserver.KeyPrefixRegionSplitPolicy
-
Deprecated.
- PREFIX_TREE - Enum constant in enum class org.apache.hadoop.hbase.io.encoding.IndexBlockEncoding
- org.apache.hadoop.hbase.filter.PrefixFilter - Class in org.apache.hadoop.hbase.filter
-
Pass results that have same row prefix.
- PrefixFilter(byte[]) - Constructor for class org.apache.hadoop.hbase.filter.PrefixFilter
- org.apache.hadoop.hbase.io.encoding.PrefixKeyDeltaEncoder - Class in org.apache.hadoop.hbase.io.encoding
-
Compress key by storing size of common prefix with previous KeyValue and storing raw size of rest.
- PrefixKeyDeltaEncoder() - Constructor for class org.apache.hadoop.hbase.io.encoding.PrefixKeyDeltaEncoder
- prefixPathStr - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
Prefix used when checking for wal membership.
- preFlush(ObserverContext<? extends RegionCoprocessorEnvironment>, FlushLifeCycleTracker) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called before the memstore is flushed to disk.
- preFlush(ObserverContext<? extends RegionCoprocessorEnvironment>, Store, InternalScanner, FlushLifeCycleTracker) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called before a Store's memstore is flushed to disk.
- preFlush(FlushLifeCycleTracker) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
Invoked before a memstore flush
- preFlush(HStore, InternalScanner, FlushLifeCycleTracker) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
Invoked before a memstore flush
- preFlushScannerOpen(ObserverContext<? extends RegionCoprocessorEnvironment>, Store, ScanOptions, FlushLifeCycleTracker) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called before we open store scanner for flush.
- preFlushScannerOpen(HStore, FlushLifeCycleTracker) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
Invoked before create StoreScanner for flush.
- preFlushSeqIDEstimation() - Method in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
-
This method is called before the flush is executed.
- preFlushSeqIDEstimation() - Method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore
- preFlushSeqIDEstimation() - Method in class org.apache.hadoop.hbase.regionserver.HStore
- preFlushSeqIDEstimation() - Method in interface org.apache.hadoop.hbase.regionserver.MemStore
-
This method is called before the flush is executed.
- preGet(Get, List<Cell>) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
Supports Coprocessor 'bypass'.
- preGetClusterMetrics() - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- preGetClusterMetrics(ObserverContext<MasterCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before get cluster status.
- preGetConfiguredNamespacesAndTablesInRSGroup(String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- preGetConfiguredNamespacesAndTablesInRSGroup(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before getting the configured namespaces and tables in the region server group.
- preGetLocks() - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- preGetLocks(ObserverContext<MasterCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before a getLocks request has been processed.
- preGetNamespaceDescriptor(String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- preGetNamespaceDescriptor(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before a getNamespaceDescriptor request has been processed.
- preGetOp(ObserverContext<? extends RegionCoprocessorEnvironment>, Get, List<Cell>) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called before the client performs a Get
- preGetProcedures() - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- preGetProcedures(ObserverContext<MasterCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before a getProcedures request has been processed.
- preGetReplicationPeerConfig(String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- preGetReplicationPeerConfig(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before get the configured ReplicationPeerConfig for the specified peer
- preGetRSGroupInfo(String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- preGetRSGroupInfo(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before getting region server group info of the passed groupName.
- preGetRSGroupInfoOfServer(ObserverContext<MasterCoprocessorEnvironment>, Address) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before getting region server group info of the passed server.
- preGetRSGroupInfoOfServer(Address) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- preGetRSGroupInfoOfTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before getting region server group info of the passed tableName.
- preGetRSGroupInfoOfTable(TableName) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- preGetTableDescriptors(List<TableName>, List<TableDescriptor>, String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- preGetTableDescriptors(ObserverContext<MasterCoprocessorEnvironment>, List<TableName>, List<TableDescriptor>, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before a getTableDescriptors request has been processed.
- preGetTableNames(List<TableDescriptor>, String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- preGetTableNames(ObserverContext<MasterCoprocessorEnvironment>, List<TableDescriptor>, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before a getTableNames request has been processed.
- preGetUserPermissions(String, String, TableName, byte[], byte[]) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- preGetUserPermissions(ObserverContext<MasterCoprocessorEnvironment>, String, String, TableName, byte[], byte[]) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before getting user permissions.
- preGrant(ObserverContext<MasterCoprocessorEnvironment>, UserPermission, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before granting user permissions.
- preGrant(UserPermission, boolean) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- preHasUserPermissions(String, List<Permission>) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- preHasUserPermissions(ObserverContext<MasterCoprocessorEnvironment>, String, List<Permission>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
- preIncrement(Increment, WALEdit) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
Supports Coprocessor 'bypass'.
- preIncrement(ObserverContext<? extends RegionCoprocessorEnvironment>, Increment) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Deprecated.since 3.0.0 and will be removed in 4.0.0. Use
RegionObserver.preIncrement(ObserverContext, Increment, WALEdit)
instead. - preIncrement(ObserverContext<? extends RegionCoprocessorEnvironment>, Increment, WALEdit) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called before Increment.
- preIncrementAfterRowLock(Increment) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
Supports Coprocessor 'bypass'.
- preIncrementAfterRowLock(ObserverContext<? extends RegionCoprocessorEnvironment>, Increment) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Deprecated.since 3.0.0 and will be removed in 4.0.0. Use
RegionObserver.preBatchMutate(ObserverContext, MiniBatchOperationInProgress)
instead. - preIsRpcThrottleEnabled() - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- preIsRpcThrottleEnabled(ObserverContext<MasterCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before getting if is rpc throttle enabled.
- preListDecommissionedRegionServers() - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- preListDecommissionedRegionServers(ObserverContext<MasterCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before list decommissioned region servers.
- preListNamespaceDescriptors(List<NamespaceDescriptor>) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- preListNamespaceDescriptors(ObserverContext<MasterCoprocessorEnvironment>, List<NamespaceDescriptor>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before a listNamespaceDescriptors request has been processed.
- preListNamespaces(List<String>) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- preListNamespaces(ObserverContext<MasterCoprocessorEnvironment>, List<String>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before a listNamespaces request has been processed.
- preListReplicationPeers(String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- preListReplicationPeers(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before list replication peers.
- preListRSGroups() - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- preListRSGroups(ObserverContext<MasterCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before listing region server group information.
- preListSnapshot(SnapshotDescription) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- preListSnapshot(ObserverContext<MasterCoprocessorEnvironment>, SnapshotDescription) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before listSnapshots request has been processed.
- preListTablesInRSGroup(String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- preListTablesInRSGroup(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before listing all tables in the region server group.
- preLockHeartbeat(ObserverContext<MasterCoprocessorEnvironment>, TableName, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before heartbeat to a lock.
- preLockHeartbeat(LockProcedure, boolean) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- preLogArchive(Path, Path) - Method in interface org.apache.hadoop.hbase.regionserver.wal.WALActionsListener
-
The WAL is going to be archived.
- preLogRoll(Path, Path) - Method in interface org.apache.hadoop.hbase.regionserver.wal.WALActionsListener
-
The WAL is going to be rolled.
- preLogRoll(Path, Path) - Method in class org.apache.hadoop.hbase.regionserver.wal.WALEventTrackerListener
- preMasterInitialization() - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- preMasterInitialization(ObserverContext<MasterCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Call before the master initialization is set to true.
- preMasterStoreFlush() - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- preMasterStoreFlush(ObserverContext<MasterCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before the master local region memstore is flushed to disk.
- preMemStoreCompaction(ObserverContext<? extends RegionCoprocessorEnvironment>, Store) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called before in memory compaction started.
- preMemStoreCompaction(HStore) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
Invoked before in memory compaction.
- preMemStoreCompactionCompact(ObserverContext<? extends RegionCoprocessorEnvironment>, Store, InternalScanner) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called before we do in memory compaction.
- preMemStoreCompactionCompact(HStore, InternalScanner) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
Invoked before compacting memstore.
- preMemStoreCompactionCompactScannerOpen(ObserverContext<? extends RegionCoprocessorEnvironment>, Store, ScanOptions) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called before we open store scanner for in memory compaction.
- preMemStoreCompactionCompactScannerOpen(HStore) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
Invoked before create StoreScanner for in memory compaction.
- preMergeRegions(RegionInfo[]) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- preMergeRegions(ObserverContext<MasterCoprocessorEnvironment>, RegionInfo[]) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before merge regions request.
- preMergeRegionsAction(RegionInfo[], User) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
Invoked just before a merge
- preMergeRegionsAction(ObserverContext<MasterCoprocessorEnvironment>, RegionInfo[]) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before the regions merge.
- preMergeRegionsCommit(RegionInfo[], List<Mutation>, User) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
Invoked before merge regions operation writes the new region to hbase:meta
- preMergeRegionsCommitAction(ObserverContext<MasterCoprocessorEnvironment>, RegionInfo[], List<Mutation>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
This will be called before update META step as part of regions merge transaction.
- preModifyColumnFamilyStoreFileTracker(ObserverContext<MasterCoprocessorEnvironment>, TableName, byte[], String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called prior to modifying a family's store file tracker.
- preModifyColumnFamilyStoreFileTracker(TableName, byte[], String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- preModifyNamespace(ObserverContext<MasterCoprocessorEnvironment>, NamespaceDescriptor, NamespaceDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called prior to modifying a namespace's properties.
- preModifyNamespace(NamespaceDescriptor, NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- preModifyTable(ObserverContext<MasterCoprocessorEnvironment>, TableName, TableDescriptor, TableDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called prior to modifying a table's properties.
- preModifyTable(TableName, TableDescriptor, TableDescriptor) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- preModifyTableAction(ObserverContext<MasterCoprocessorEnvironment>, TableName, TableDescriptor, TableDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called prior to modifying a table's properties.
- preModifyTableAction(TableName, TableDescriptor, TableDescriptor, User) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- preModifyTableStoreFileTracker(ObserverContext<MasterCoprocessorEnvironment>, TableName, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called prior to modifying a table's store file tracker.
- preModifyTableStoreFileTracker(TableName, String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- preMove(RegionInfo, ServerName, ServerName) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- preMove(ObserverContext<MasterCoprocessorEnvironment>, RegionInfo, ServerName, ServerName) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called prior to moving a given region from one region server to another.
- preMoveServers(Set<Address>, String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- preMoveServers(ObserverContext<MasterCoprocessorEnvironment>, Set<Address>, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before servers are moved to target region server group
- preMoveServersAndTables(Set<Address>, Set<TableName>, String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- preMoveServersAndTables(ObserverContext<MasterCoprocessorEnvironment>, Set<Address>, Set<TableName>, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before servers are moved to target region server group
- preMoveTables(Set<TableName>, String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- preMoveTables(ObserverContext<MasterCoprocessorEnvironment>, Set<TableName>, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before tables are moved to target region server group
- preOpen() - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
Invoked before a region open.
- preOpen(ObserverContext<? extends RegionCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called before the region is reported as open to the master.
- prepare(E) - Method in class org.apache.hadoop.hbase.coprocessor.ObserverContextImpl
- prepare(ExtendedCell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.NewVersionBehaviorTracker
-
Reset the map if it is different with the last Cell.
- PREPARE_INCREMENTAL - Enum constant in enum class org.apache.hadoop.hbase.backup.BackupInfo.BackupPhase
- prepareBulkLoad(byte[], String, boolean, String) - Method in interface org.apache.hadoop.hbase.regionserver.HRegion.BulkLoadListener
-
Called before an HFile is actually loaded
- prepareBulkLoad(HRegion, ClientProtos.PrepareBulkLoadRequest) - Method in class org.apache.hadoop.hbase.regionserver.SecureBulkLoadManager
- prepareBulkLoad(TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncClusterConnection
-
Return the token for this bulk load.
- prepareBulkLoad(RpcController, ClientProtos.PrepareBulkLoadRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
- prepareDecoding(int, int, ByteBuff, ByteBuff) - Method in interface org.apache.hadoop.hbase.io.encoding.HFileBlockDecodingContext
-
Perform all actions that need to be done before the encoder's real decoding process.
- prepareDecoding(int, int, ByteBuff, ByteBuff) - Method in class org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultDecodingContext
- prepareEncoding(DataOutputStream) - Method in class org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultEncodingContext
-
prepare to start a new encoding.
- prepareForBlockReader(boolean) - Method in class org.apache.hadoop.hbase.io.FSDataInputStreamWrapper
-
Prepares the streams for block reader.
- prepareTask(String) - Method in interface org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination
-
Deprecated.Prepare the new task
- prepareTask(String) - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
- prepend(TNode, TNode) - Static method in class org.apache.hadoop.hbase.util.AvlUtil.AvlIterableList
-
Prepend a node to the tree
- prepend(TNode, TNode, TNode) - Static method in class org.apache.hadoop.hbase.util.AvlUtil.AvlIterableList
-
Prepend a node to the tree before a specific node
- prependPBMagic(byte[]) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Prepend the passed bytes with four bytes of magic,
ProtobufMagic.PB_MAGIC
, to flag what follows as a protobuf in hbase. - prePrepareBulkLoad(ObserverContext<RegionCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.BulkLoadObserver
-
Called as part of SecureBulkLoadEndpoint.prepareBulkLoad() RPC call.
- prePrepareBulkLoad(User) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
- prePrepareTimeStampForDeleteVersion(Mutation, Cell, byte[], Get) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
Supports Coprocessor 'bypass'.
- prePrepareTimeStampForDeleteVersion(ObserverContext<? extends RegionCoprocessorEnvironment>, Mutation, Cell, byte[], Get) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Deprecated.Since hbase-2.0.0. No replacement. To be removed in hbase-4.0.0 and replaced with something that doesn't expose IntefaceAudience.Private classes. VisibilityController still needs this, need to change the logic there first.
- preProcessError(Throwable) - Method in class org.apache.hadoop.hbase.client.AsyncRegionReplicationRetryingCaller
- preProcessError(Throwable) - Method in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCaller
- prePut(Put, WALEdit) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
Supports Coprocessor 'bypass'.
- prePut(ObserverContext<? extends RegionCoprocessorEnvironment>, Put, WALEdit) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called before the client stores a value.
- prePut(ObserverContext<? extends RegionCoprocessorEnvironment>, Put, WALEdit, Durability) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Deprecated.since 3.0.0 and will be removed in 4.0.0. Use
RegionObserver.prePut(ObserverContext, Put, WALEdit)
instead. - preRecommissionRegionServer(ObserverContext<MasterCoprocessorEnvironment>, ServerName, List<byte[]>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before recommission region server.
- preRecommissionRegionServer(ServerName, List<byte[]>) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- preRegionOffline(RegionInfo) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- preRegionOffline(ObserverContext<MasterCoprocessorEnvironment>, RegionInfo) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called prior to marking a given region as offline.
- preRemoveReplicationPeer(String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- preRemoveReplicationPeer(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before remove a replication peer
- preRemoveRSGroup(String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- preRemoveRSGroup(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before a region server group is removed
- preRemoveServers(Set<Address>) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- preRemoveServers(ObserverContext<MasterCoprocessorEnvironment>, Set<Address>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before servers are removed from rsgroup
- preRenameRSGroup(String, String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- preRenameRSGroup(ObserverContext<MasterCoprocessorEnvironment>, String, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before rename rsgroup.
- preReplayWALs(RegionInfo, Path) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
- preReplayWALs(ObserverContext<? extends RegionCoprocessorEnvironment>, RegionInfo, Path) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called before replaying WALs for this region.
- preReplicateLogEntries() - Method in class org.apache.hadoop.hbase.regionserver.RegionServerCoprocessorHost
- preReplicateLogEntries(ObserverContext<RegionServerCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionServerObserver
-
Deprecated.As of release 2.0.0 with out any replacement, plan to remove in 4.0.0. This is maintained for internal usage by AccessController. Do not use these hooks in custom co-processors.
- preReplicationSinkBatchMutate(ObserverContext<RegionServerCoprocessorEnvironment>, AdminProtos.WALEntry, Mutation) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionServerObserver
-
This will be called before replication sink mutations are executed on the sink table as part of batch call.
- preReplicationSinkBatchMutate(AdminProtos.WALEntry, Mutation) - Method in class org.apache.hadoop.hbase.regionserver.RegionServerCoprocessorHost
- preRequestLock(String, TableName, RegionInfo[], LockType, String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- preRequestLock(ObserverContext<MasterCoprocessorEnvironment>, String, TableName, RegionInfo[], String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before new LockProcedure is queued.
- preRestoreSnapshot(SnapshotDescription, TableDescriptor) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- preRestoreSnapshot(ObserverContext<MasterCoprocessorEnvironment>, SnapshotDescription, TableDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before a snapshot is restored.
- preRevoke(ObserverContext<MasterCoprocessorEnvironment>, UserPermission) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before revoking user permissions.
- preRevoke(UserPermission) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- preRollWALWriterRequest() - Method in class org.apache.hadoop.hbase.regionserver.RegionServerCoprocessorHost
- preRollWALWriterRequest(ObserverContext<RegionServerCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionServerObserver
-
This will be called before executing user request to roll a region server WAL.
- preScannerClose(ObserverContext<? extends RegionCoprocessorEnvironment>, InternalScanner) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called before the client closes a scanner.
- preScannerClose(InternalScanner) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
Supports Coprocessor 'bypass'.
- preScannerNext(ObserverContext<? extends RegionCoprocessorEnvironment>, InternalScanner, List<Result>, int, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called before the client asks for the next row on a scanner.
- preScannerNext(InternalScanner, List<Result>, int) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
- preScannerOpen(Scan) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
- preScannerOpen(ObserverContext<? extends RegionCoprocessorEnvironment>, Scan) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called before the client opens a new scanner.
- preSetNamespaceQuota(String, GlobalQuotaSettings) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- preSetNamespaceQuota(ObserverContext<MasterCoprocessorEnvironment>, String, GlobalQuotaSettings) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before the quota for the namespace is stored.
- preSetRegionServerQuota(String, GlobalQuotaSettings) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- preSetRegionServerQuota(ObserverContext<MasterCoprocessorEnvironment>, String, GlobalQuotaSettings) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before the quota for the region server is stored.
- preSetSplitOrMergeEnabled(boolean, MasterSwitchType) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- preSetSplitOrMergeEnabled(ObserverContext<MasterCoprocessorEnvironment>, boolean, MasterSwitchType) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called prior to setting split / merge switch Supports Coprocessor 'bypass'.
- preSetTableQuota(ObserverContext<MasterCoprocessorEnvironment>, TableName, GlobalQuotaSettings) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before the quota for the table is stored.
- preSetTableQuota(TableName, GlobalQuotaSettings) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- preSetUserQuota(String, String, GlobalQuotaSettings) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- preSetUserQuota(String, GlobalQuotaSettings) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- preSetUserQuota(String, TableName, GlobalQuotaSettings) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- preSetUserQuota(ObserverContext<MasterCoprocessorEnvironment>, String, String, GlobalQuotaSettings) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before the quota for the user on the specified namespace is stored.
- preSetUserQuota(ObserverContext<MasterCoprocessorEnvironment>, String, GlobalQuotaSettings) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before the quota for the user is stored.
- preSetUserQuota(ObserverContext<MasterCoprocessorEnvironment>, String, TableName, GlobalQuotaSettings) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before the quota for the user on the specified table is stored.
- preShutdown() - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- preShutdown(ObserverContext<MasterCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called prior to shutting down the full HBase cluster, including this
HMaster
process. - preSnapshot(SnapshotDescription, TableDescriptor, User) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- preSnapshot(ObserverContext<MasterCoprocessorEnvironment>, SnapshotDescription, TableDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before a new snapshot is taken.
- preSnapshotOperation() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
Sets the store up for a region level snapshot operation.
- preSplitAfterMETAAction(User) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
This will be called after update META step as part of split table region procedure.
- preSplitBeforeMETAAction(byte[], List<Mutation>, User) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
This will be called before update META step as part of split table region procedure.
- preSplitRegion(ObserverContext<MasterCoprocessorEnvironment>, TableName, byte[]) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before the split region procedure is called.
- preSplitRegion(TableName, byte[]) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
Invoked just before calling the split region procedure
- preSplitRegionAction(ObserverContext<MasterCoprocessorEnvironment>, TableName, byte[]) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before the region is split.
- preSplitRegionAction(TableName, byte[], User) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
Invoked just before a split
- preSplitRegionAfterMETAAction(ObserverContext<MasterCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
This will be called after update META step as part of split transaction
- preSplitRegionBeforeMETAAction(ObserverContext<MasterCoprocessorEnvironment>, byte[], List<Mutation>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
This will be called before update META step as part of split transaction.
- org.apache.hadoop.hbase.regionserver.throttle.PressureAwareCompactionThroughputController - Class in org.apache.hadoop.hbase.regionserver.throttle
-
A throughput controller which uses the follow schema to limit throughput If compaction pressure is greater than 1.0, no limitation. In off peak hours, use a fixed throughput limitation "hbase.hstore.compaction.throughput.offpeak" In normal hours, the max throughput is tuned between "hbase.hstore.compaction.throughput.lower.bound" and "hbase.hstore.compaction.throughput.higher.bound", using the formula "lower + (higer - lower) * compactionPressure", where compactionPressure is in range [0.0, 1.0]
- PressureAwareCompactionThroughputController() - Constructor for class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareCompactionThroughputController
- org.apache.hadoop.hbase.regionserver.throttle.PressureAwareFlushThroughputController - Class in org.apache.hadoop.hbase.regionserver.throttle
-
A throughput controller which uses the follow schema to limit throughput If flush pressure is greater than or equal to 1.0, no limitation. In normal case, the max throughput is tuned between "hbase.hstore.flush.throughput.lower.bound" and "hbase.hstore.flush.throughput.upper.bound", using the formula "lower + (upper - lower) * flushPressure", where flushPressure is in range [0.0, 1.0)
- PressureAwareFlushThroughputController() - Constructor for class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareFlushThroughputController
- org.apache.hadoop.hbase.regionserver.throttle.PressureAwareThroughputController - Class in org.apache.hadoop.hbase.regionserver.throttle
- PressureAwareThroughputController() - Constructor for class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareThroughputController
- preStop(String, User) - Method in class org.apache.hadoop.hbase.regionserver.RegionServerCoprocessorHost
- preStopMaster() - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- preStopMaster(ObserverContext<MasterCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called immediately prior to stopping this
HMaster
process. - preStopRegionServer(ObserverContext<RegionServerCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionServerObserver
-
Called before stopping region server.
- preStoreFileReaderOpen(FileSystem, Path, FSDataInputStreamWrapper, long, CacheConfig, Reference) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
- preStoreFileReaderOpen(ObserverContext<? extends RegionCoprocessorEnvironment>, FileSystem, Path, FSDataInputStreamWrapper, long, CacheConfig, Reference, StoreFileReader) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Deprecated.For Phoenix only, StoreFileReader is not a stable interface.
- preStoreScannerOpen(ObserverContext<? extends RegionCoprocessorEnvironment>, Store, ScanOptions) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called before a store opens a new scanner.
- preStoreScannerOpen(HStore, Scan) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
Called before open store scanner for user scan.
- preSwitchExceedThrottleQuota(boolean) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- preSwitchExceedThrottleQuota(ObserverContext<MasterCoprocessorEnvironment>, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before switching exceed throttle quota state.
- preSwitchRpcThrottle(boolean) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- preSwitchRpcThrottle(ObserverContext<MasterCoprocessorEnvironment>, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before switching rpc throttle enabled state.
- preTableFlush(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before the table memstore is flushed to disk.
- preTableFlush(TableName) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- preTransitReplicationPeerSyncReplicationState(String, SyncReplicationState) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- preTransitReplicationPeerSyncReplicationState(ObserverContext<MasterCoprocessorEnvironment>, String, SyncReplicationState) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before transit current cluster state for the specified synchronous replication peer
- preTruncateRegion(RegionInfo) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
Invoked just before calling the truncate region procedure
- preTruncateRegion(ObserverContext<MasterCoprocessorEnvironment>, RegionInfo) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before the truncate region procedure is called.
- preTruncateRegionAction(RegionInfo, User) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
Invoked just before calling the truncate region procedure
- preTruncateRegionAction(ObserverContext<MasterCoprocessorEnvironment>, RegionInfo) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before the region is truncated.
- preTruncateTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before
HMaster
truncates a table. - preTruncateTable(TableName) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- preTruncateTableAction(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before
HMaster
truncates a table. - preTruncateTableAction(TableName, User) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- prettyPrint(String) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Use logging.
- org.apache.hadoop.hbase.util.PrettyPrinter - Class in org.apache.hadoop.hbase.util
- PrettyPrinter() - Constructor for class org.apache.hadoop.hbase.util.PrettyPrinter
- org.apache.hadoop.hbase.util.PrettyPrinter.Unit - Enum Class in org.apache.hadoop.hbase.util
- preUnassign(RegionInfo) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- preUnassign(ObserverContext<MasterCoprocessorEnvironment>, RegionInfo) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called prior to unassigning a given region.
- preUpdate(MutableSegment, ExtendedCell, MemStoreSizing) - Method in class org.apache.hadoop.hbase.regionserver.AbstractMemStore
-
Issue any synchronization and test needed before applying the update
- preUpdate(MutableSegment, ExtendedCell, MemStoreSizing) - Method in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
-
Issue any synchronization and test needed before applying the update For compacting memstore this means checking the update can increase the size without overflow
- preUpdate(MutableSegment, ExtendedCell, MemStoreSizing) - Method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore
- preUpdateConfiguration(Configuration) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- preUpdateConfiguration(Configuration) - Method in class org.apache.hadoop.hbase.regionserver.RegionServerCoprocessorHost
- preUpdateMasterConfiguration(ObserverContext<MasterCoprocessorEnvironment>, Configuration) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before reloading the HMaster's
Configuration
from disk - preUpdateRegionServerConfiguration(ObserverContext<RegionServerCoprocessorEnvironment>, Configuration) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionServerObserver
-
Called before reloading the RegionServer's
Configuration
from disk - preUpdateReplicationPeerConfig(String, ReplicationPeerConfig) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- preUpdateReplicationPeerConfig(ObserverContext<MasterCoprocessorEnvironment>, String, ReplicationPeerConfig) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before update peerConfig for the specified peer
- preUpdateRSGroupConfig(String, Map<String, String>) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
- preUpdateRSGroupConfig(ObserverContext<MasterCoprocessorEnvironment>, String, Map<String, String>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before update rsgroup config.
- prevBlocks - Variable in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
- prevCell - Variable in class org.apache.hadoop.hbase.io.encoding.EncodingState
-
The previous Cell the encoder encoded.
- org.apache.hadoop.hbase.io.hfile.PreviousBlockCompressionRatePredicator - Class in org.apache.hadoop.hbase.io.hfile
-
This BlockCompressedSizePredicator implementation adjusts the block size limit based on the compression rate of the block contents read so far.
- PreviousBlockCompressionRatePredicator() - Constructor for class org.apache.hadoop.hbase.io.hfile.PreviousBlockCompressionRatePredicator
- previousKey(KeyValue) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
-
Decrement the timestamp.
- preWALAppend(ObserverContext<? extends RegionCoprocessorEnvironment>, WALKey, WALEdit) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called just before the WAL Entry is appended to the WAL.
- preWALAppend(WALKey, WALEdit) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
- preWALRoll(Path, Path) - Method in class org.apache.hadoop.hbase.regionserver.wal.WALCoprocessorHost
-
Called before rolling the current WAL
- preWALRoll(ObserverContext<? extends WALCoprocessorEnvironment>, Path, Path) - Method in interface org.apache.hadoop.hbase.coprocessor.WALObserver
-
Called before rolling the current WAL
- preWALWrite(RegionInfo, WALKey, WALEdit) - Method in class org.apache.hadoop.hbase.regionserver.wal.WALCoprocessorHost
- preWALWrite(ObserverContext<? extends WALCoprocessorEnvironment>, RegionInfo, WALKey, WALEdit) - Method in interface org.apache.hadoop.hbase.coprocessor.WALObserver
-
Called before a
WALEdit
is writen to WAL. - PRIMARY - Enum constant in enum class org.apache.hadoop.hbase.favored.FavoredNodesPlan.Position
- PRIMARY_CALL_TIMEOUT_MICROSECOND - Static variable in class org.apache.hadoop.hbase.client.ConnectionConfiguration
- PRIMARY_CALL_TIMEOUT_MICROSECOND_DEFAULT - Static variable in class org.apache.hadoop.hbase.client.ConnectionConfiguration
- PRIMARY_SCAN_TIMEOUT_MICROSECOND - Static variable in class org.apache.hadoop.hbase.client.ConnectionConfiguration
- PRIMARY_SCAN_TIMEOUT_MICROSECOND_DEFAULT - Static variable in class org.apache.hadoop.hbase.client.ConnectionConfiguration
- principal - Static variable in class org.apache.hadoop.hbase.thrift.HttpDoAsClient
- print(boolean) - Method in class org.apache.hadoop.hbase.master.AssignmentVerificationReport
- print(char) - Method in interface org.apache.hadoop.hbase.hbtop.terminal.TerminalPrinter
- print(double) - Method in interface org.apache.hadoop.hbase.hbtop.terminal.TerminalPrinter
- print(float) - Method in interface org.apache.hadoop.hbase.hbtop.terminal.TerminalPrinter
- print(int) - Method in interface org.apache.hadoop.hbase.hbtop.terminal.TerminalPrinter
- print(long) - Method in interface org.apache.hadoop.hbase.hbtop.terminal.TerminalPrinter
- print(short) - Method in interface org.apache.hadoop.hbase.hbtop.terminal.TerminalPrinter
- print(Object) - Method in interface org.apache.hadoop.hbase.hbtop.terminal.TerminalPrinter
- print(Object) - Static method in class org.apache.hadoop.hbase.util.JRubyFormat
- print(String) - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.batch.BatchTerminalPrinter
- print(String) - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.TerminalPrinterImpl
- print(String) - Method in interface org.apache.hadoop.hbase.hbtop.terminal.TerminalPrinter
- print(String) - Method in interface org.apache.hadoop.hbase.util.HbckErrorReporter
-
Deprecated.
- printAssignmentPlan(FavoredNodesPlan) - Static method in class org.apache.hadoop.hbase.master.RegionPlacementMaintainer
-
Print the assignment plan to the system output stream
- printCell(PrintStream, Map<String, Object>, boolean, boolean) - Static method in class org.apache.hadoop.hbase.wal.WALPrettyPrinter
- printDispersionScores(TableName, SnapshotOfRegionAssignmentFromMeta, int, FavoredNodesPlan, boolean) - Method in class org.apache.hadoop.hbase.master.RegionPlacementMaintainer
- printFormat(String, Object...) - Method in interface org.apache.hadoop.hbase.hbtop.terminal.TerminalPrinter
- printLocalityAndDispersionForCurrentPlan(Map<String, Map<String, Float>>) - Method in class org.apache.hadoop.hbase.master.RegionPlacementMaintainer
- printRow(TRowResult) - Static method in class org.apache.hadoop.hbase.util.ClientUtils
-
copy values into a TreeMap to get them in sorted order and print it
- printStackTrace(Thread) - Static method in class org.apache.hadoop.hbase.util.Threads
- printStatistics() - Method in class org.apache.hadoop.hbase.mob.MobFileCache
-
Prints the statistics.
- printThreadInfo(PrintStream, String) - Static method in class org.apache.hadoop.hbase.util.Threads
-
Print all of the thread's information and stack traces.
- printToolUsage() - Method in class org.apache.hadoop.hbase.backup.BackupDriver
- printToolUsage() - Method in class org.apache.hadoop.hbase.backup.RestoreDriver
- printUsage() - Method in class org.apache.hadoop.hbase.mapreduce.RowCounter
- printUsage() - Method in class org.apache.hadoop.hbase.PerformanceEvaluation
- printUsage() - Method in class org.apache.hadoop.hbase.snapshot.ExportSnapshot
- printUsage() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo
- printUsage() - Method in class org.apache.hadoop.hbase.tool.coprocessor.CoprocessorValidator
- printUsage() - Method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
- printUsage(String) - Static method in class org.apache.hadoop.hbase.PerformanceEvaluation
- printUsage(String, String) - Static method in class org.apache.hadoop.hbase.PerformanceEvaluation
- printUsage(String, String, String) - Method in class org.apache.hadoop.hbase.mapreduce.RowCounter
- printUsage(String, String, String) - Method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
- printUsage(Options) - Static method in class org.apache.hadoop.hbase.util.compaction.MajorCompactor
- printUsageAndExit() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- printUsageAndExit(String, int) - Static method in class org.apache.hadoop.hbase.PerformanceEvaluation
- printUsageAndExit(Options, int) - Method in class org.apache.hadoop.hbase.thrift.ThriftServer
- priority - Variable in class org.apache.hadoop.hbase.coprocessor.BaseEnvironment
-
Chaining priority
- priority - Variable in class org.apache.hadoop.hbase.HBaseRpcServicesBase
- priority - Variable in class org.apache.hadoop.hbase.ipc.PluggableBlockingQueue
- priority() - Element in annotation interface org.apache.hadoop.hbase.ipc.QosPriority
- PRIORITY - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
- PRIORITY_HIGHEST - Static variable in interface org.apache.hadoop.hbase.Coprocessor
-
Highest installation priority
- PRIORITY_LOWEST - Static variable in interface org.apache.hadoop.hbase.Coprocessor
-
Lowest installation priority
- PRIORITY_QUEUE_DESC - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
- PRIORITY_QUEUE_NAME - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
- PRIORITY_SYSTEM - Static variable in interface org.apache.hadoop.hbase.Coprocessor
-
High (system) installation priority
- PRIORITY_UNSET - Static variable in class org.apache.hadoop.hbase.HConstants
-
QOS attributes: these attributes are used to demarcate RPC call processing by different set of handlers.
- PRIORITY_USER - Static variable in interface org.apache.hadoop.hbase.Coprocessor
-
Default installation priority for user coprocessors
- PRIORITY_USER - Static variable in interface org.apache.hadoop.hbase.regionserver.Store
-
The default priority for user-specified compaction requests.
- org.apache.hadoop.hbase.ipc.PriorityFunction - Interface in org.apache.hadoop.hbase.ipc
-
Function to figure priority of incoming request.
- PRIVACY - Enum constant in enum class org.apache.hadoop.hbase.security.SaslUtil.QualityOfProtection
- org.apache.hadoop.hbase.PrivateCellUtil - Class in org.apache.hadoop.hbase
-
Utility methods helpful slinging
Cell
instances. - org.apache.hadoop.hbase.PrivateConstants - Class in org.apache.hadoop.hbase
-
Constants intended to be used internally.
- process() - Method in class org.apache.hadoop.hbase.regionserver.CompactedHFilesDischargeHandler
- process(WatchedEvent) - Method in class org.apache.hadoop.hbase.chaos.ChaosAgent
- process(WatchedEvent) - Method in class org.apache.hadoop.hbase.zookeeper.EmptyWatcher
- process(WatchedEvent) - Method in class org.apache.hadoop.hbase.zookeeper.ZKWatcher
-
Method called from ZooKeeper for events and connection status.
- PROCESS_CALL_TIME_DESC - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
- PROCESS_CALL_TIME_NAME - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
- processedCall(int) - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
- processedCall(int) - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceImpl
- processException(Throwable) - Method in class org.apache.hadoop.hbase.rest.ResourceBase
- processFile(Configuration, Path) - Method in class org.apache.hadoop.hbase.wal.WALPrettyPrinter
-
reads a log file and outputs its contents, one transaction at a time, as specified by the currently configured options the HBase configuration relevant to this log file the path of the log file to be read may be unable to access the configured filesystem or requested file.
- processFile(Path, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFilePrettyPrinter
- processFileArchivals(RegionServerStatusProtos.FileArchiveNotificationRequest, Connection, Configuration, FileSystem) - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
- processFirstDataBlock() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.EncodedScanner
- processFirstDataBlock() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
- processKV(ImmutableBytesWritable, Result, Mapper.Context, Put, Delete) - Method in class org.apache.hadoop.hbase.mapreduce.Import.Importer
- processOldArgs(List<String>) - Method in class org.apache.hadoop.hbase.mapreduce.RowCounter
- processOldArgs(List<String>) - Method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
-
For backward compatibility.
- processOptions(String[]) - Method in class org.apache.hadoop.hbase.thrift.ThriftServer
-
Parse the command line options to set parameters the conf.
- processOptions(CommandLine) - Method in class org.apache.hadoop.hbase.backup.BackupDriver
- processOptions(CommandLine) - Method in class org.apache.hadoop.hbase.backup.RestoreDriver
- processOptions(CommandLine) - Method in class org.apache.hadoop.hbase.mapreduce.RowCounter
- processOptions(CommandLine) - Method in class org.apache.hadoop.hbase.ScanPerformanceEvaluation
- processOptions(CommandLine) - Method in class org.apache.hadoop.hbase.snapshot.CreateSnapshot
- processOptions(CommandLine) - Method in class org.apache.hadoop.hbase.snapshot.ExportSnapshot
- processOptions(CommandLine) - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo
- processOptions(CommandLine) - Method in class org.apache.hadoop.hbase.tool.coprocessor.CoprocessorValidator
- processOptions(CommandLine) - Method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
-
This method is called to process the options after they have been parsed.
- processOptions(CommandLine) - Method in class org.apache.hadoop.hbase.util.LoadTestTool
- processOptions(CommandLine) - Method in class org.apache.hadoop.hbase.util.RegionMover
- processor - Variable in class org.apache.hadoop.hbase.thrift.ThriftServer
- processParameter(String, String) - Method in class org.apache.hadoop.hbase.io.crypto.KeyStoreKeyProvider
- processParameters(URI) - Method in class org.apache.hadoop.hbase.io.crypto.KeyStoreKeyProvider
- processResult(int, String, Object) - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination.DeleteAsyncCallback
- processResult(int, String, Object, byte[], Stat) - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination.GetDataAsyncCallback
- processResult(int, String, Object, String) - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination.CreateAsyncCallback
- processResult(int, String, Object, String) - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination.CreateRescanAsyncCallback
- org.apache.hadoop.hbase.util.ProcessUtils - Class in org.apache.hadoop.hbase.util
-
Process related utilities.
- org.apache.hadoop.hbase.http.ProfileOutputServlet - Class in org.apache.hadoop.hbase.http
-
Servlet to serve files generated by
ProfileServlet
- ProfileOutputServlet() - Constructor for class org.apache.hadoop.hbase.http.ProfileOutputServlet
- org.apache.hadoop.hbase.http.ProfileServlet - Class in org.apache.hadoop.hbase.http
-
Servlet that runs async-profiler as web-endpoint.
- ProfileServlet() - Constructor for class org.apache.hadoop.hbase.http.ProfileServlet
- org.apache.hadoop.hbase.http.ProfileServlet.DisabledServlet - Class in org.apache.hadoop.hbase.http
- progress() - Method in interface org.apache.hadoop.hbase.util.CancelableProgressable
-
Report progress.
- progress() - Method in interface org.apache.hadoop.hbase.util.HbckErrorReporter
-
Deprecated.
- PROGRESS - Enum constant in enum class org.apache.hadoop.hbase.backup.BackupRestoreConstants.BackupCommand
- progressInfo() - Method in class org.apache.hadoop.hbase.util.MultiThreadedAction
-
Returns a task-specific progress string
- progressInfo() - Method in class org.apache.hadoop.hbase.util.MultiThreadedReader
- progressInfo() - Method in class org.apache.hadoop.hbase.util.MultiThreadedWriterBase
- org.apache.hadoop.hbase.http.prometheus.PrometheusHadoopServlet - Class in org.apache.hadoop.hbase.http.prometheus
- PrometheusHadoopServlet() - Constructor for class org.apache.hadoop.hbase.http.prometheus.PrometheusHadoopServlet
- org.apache.hadoop.hbase.conf.PropagatingConfigurationObserver - Interface in org.apache.hadoop.hbase.conf
-
This extension to ConfigurationObserver allows the configuration to propagate to the children of the current
ConfigurationObserver
. - org.apache.hadoop.hbase.io.asyncfs.ProtobufDecoder - Class in org.apache.hadoop.hbase.io.asyncfs
-
Modified based on io.netty.handler.codec.protobuf.ProtobufDecoder.
- ProtobufDecoder(Object) - Constructor for class org.apache.hadoop.hbase.io.asyncfs.ProtobufDecoder
- org.apache.hadoop.hbase.regionserver.wal.ProtobufLogWriter - Class in org.apache.hadoop.hbase.regionserver.wal
-
Writer for protobuf-based WAL.
- ProtobufLogWriter() - Constructor for class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogWriter
- org.apache.hadoop.hbase.rest.ProtobufMessageHandler - Interface in org.apache.hadoop.hbase.rest
-
Common interface for models capable of supporting protobuf marshalling and unmarshalling.
- org.apache.hadoop.hbase.rest.ProtobufStreamingOutput - Class in org.apache.hadoop.hbase.rest
- ProtobufStreamingOutput(ResultScanner, String, int, int) - Constructor for class org.apache.hadoop.hbase.rest.ProtobufStreamingOutput
- org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil - Class in org.apache.hadoop.hbase.shaded.protobuf
-
Protobufs utility.
- org.apache.hadoop.hbase.regionserver.wal.ProtobufWALStreamReader - Class in org.apache.hadoop.hbase.regionserver.wal
-
A one way stream reader for reading protobuf based WAL file.
- ProtobufWALStreamReader() - Constructor for class org.apache.hadoop.hbase.regionserver.wal.ProtobufWALStreamReader
- org.apache.hadoop.hbase.regionserver.wal.ProtobufWALTailingReader - Class in org.apache.hadoop.hbase.regionserver.wal
-
A WAL reader for replication.
- ProtobufWALTailingReader() - Constructor for class org.apache.hadoop.hbase.regionserver.wal.ProtobufWALTailingReader
- PROTOCOL_HTTP - Static variable in class org.apache.hadoop.hbase.http.log.LogLevel
- PROTOCOL_HTTPS - Static variable in class org.apache.hadoop.hbase.http.log.LogLevel
- provide() - Method in class org.apache.hadoop.hbase.http.jersey.SupplierFactoryAdapter
- provideHint - Variable in class org.apache.hadoop.hbase.filter.PrefixFilter
- providerId - Variable in class org.apache.hadoop.hbase.wal.AbstractWALProvider
- PROXYUSER_PREFIX - Static variable in class org.apache.hadoop.hbase.http.ProxyUserAuthenticationFilter
- org.apache.hadoop.hbase.http.ProxyUserAuthenticationFilter - Class in org.apache.hadoop.hbase.http
-
This file has been copied directly (changing only the package name and and the ASF license text format, and adding the Yetus annotations) from Hadoop, as the Hadoop version that HBase depends on doesn't have it yet (as of 2020 Apr 24, there is no Hadoop release that has it either).
- ProxyUserAuthenticationFilter() - Constructor for class org.apache.hadoop.hbase.http.ProxyUserAuthenticationFilter
- publish(ClusterMetrics) - Method in class org.apache.hadoop.hbase.master.ClusterStatusPublisher.MulticastPublisher
- publish(ClusterMetrics) - Method in interface org.apache.hadoop.hbase.master.ClusterStatusPublisher.Publisher
- purge() - Method in class org.apache.hadoop.hbase.util.ObjectPool
-
Removes stale references of shared objects from the pool.
- purgeTimeout - Variable in class org.apache.hadoop.hbase.ipc.SimpleRpcServer
-
Deprecated.
- pushActiveToPipeline(MutableSegment, boolean) - Method in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
-
NOTE: When
CompactingMemStore.flushInMemory(MutableSegment)
calls this method, due to concurrent writes and because we first add cell size to currActive.getDataSize and then actually add cell to currActive.cellSet, it is possible that currActive.getDataSize could not accommodate cellToAdd but currActive.cellSet is still empty if pending writes which not yet add cells to currActive.cellSet,so forCompactingMemStore.flushInMemory(MutableSegment)
,checkEmpty parameter is false. - pushHead(MutableSegment) - Method in class org.apache.hadoop.hbase.regionserver.CompactionPipeline
- put(byte) - Method in class org.apache.hadoop.hbase.nio.ByteBuff
-
Writes a byte to this ByteBuff at the current position and increments the position
- put(byte) - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
Writes a byte to this MBB at the current position and increments the position
- put(byte) - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
- put(byte) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
Store
val
at the next position in this range. - put(byte) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
- put(byte) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
- put(byte[]) - Method in class org.apache.hadoop.hbase.nio.ByteBuff
-
Copies from the given byte[] to this ByteBuff
- put(byte[]) - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
Copies from the given byte[] to this MBB
- put(byte[]) - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
- put(byte[]) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
Store the content of
val
in this range, starting at the next position. - put(byte[]) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
- put(byte[]) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
- put(byte[], byte[]) - Method in class org.apache.hadoop.hbase.io.hfile.HFileInfo
- put(byte[], int) - Method in enum class org.apache.hadoop.hbase.io.hfile.BlockType
-
Put the magic record out to the specified byte array position.
- put(byte[], int, int) - Method in class org.apache.hadoop.hbase.nio.ByteBuff
-
Copies from the given byte[] to this ByteBuff
- put(byte[], int, int) - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
Copies from the given byte[] to this MBB.
- put(byte[], int, int) - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
- put(byte[], int, int) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
Store
length
bytes fromval
into this range. - put(byte[], int, int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
- put(byte[], int, int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
- put(int, byte) - Method in class org.apache.hadoop.hbase.nio.ByteBuff
-
Writes a byte to this ByteBuff at the given index
- put(int, byte) - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
Writes a byte to this MBB at the given index and won't affect the position of any of the buffers.
- put(int, byte) - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
- put(int, byte) - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Store
val
atindex
. - put(int, byte) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
- put(int, byte) - Method in class org.apache.hadoop.hbase.util.SimpleByteRange
- put(int, byte) - Method in class org.apache.hadoop.hbase.util.SimpleMutableByteRange
- put(int, byte) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
- put(int, byte) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
- put(int, byte[]) - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Store
val
atindex
. - put(int, byte[]) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
- put(int, byte[]) - Method in class org.apache.hadoop.hbase.util.SimpleByteRange
- put(int, byte[]) - Method in class org.apache.hadoop.hbase.util.SimpleMutableByteRange
- put(int, byte[]) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
- put(int, byte[]) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
- put(int, byte[], int, int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Store
length
bytes fromval
into this range, starting atindex
. - put(int, byte[], int, int) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
- put(int, byte[], int, int) - Method in class org.apache.hadoop.hbase.util.SimpleByteRange
- put(int, byte[], int, int) - Method in class org.apache.hadoop.hbase.util.SimpleMutableByteRange
- put(int, byte[], int, int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
- put(int, byte[], int, int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
- put(int, ByteBuff, int, int) - Method in class org.apache.hadoop.hbase.nio.ByteBuff
-
Copies the contents from the src ByteBuff to this ByteBuff.
- put(int, ByteBuff, int, int) - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
Copies from a src BB to this MBB.
- put(int, ByteBuff, int, int) - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
- put(E) - Method in class org.apache.hadoop.hbase.util.BoundedPriorityBlockingQueue
- put(Runnable) - Method in class org.apache.hadoop.hbase.thrift.CallQueue
- put(String, String, byte[]) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Send a PUT request
- put(String, String, byte[], Header) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Send a PUT request
- put(String, Header[], byte[]) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Send a PUT request
- put(List<Put>) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
Puts some data in the table, in batch.
- put(List<Put>) - Method in interface org.apache.hadoop.hbase.client.Table
-
Batch puts the specified data into the table.
- put(K, V) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
- put(Put) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
Puts some data to the table.
- put(Put) - Method in interface org.apache.hadoop.hbase.client.Table
-
Puts some data in the table.
- put(Put) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
- put(Put) - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Puts some data in the table.
- put(RegionInfo, long) - Method in class org.apache.hadoop.hbase.quotas.NoOpRegionSizeStore
- put(RegionInfo, long) - Method in interface org.apache.hadoop.hbase.quotas.RegionSizeStore
-
Atomically sets the given
size
for a region. - put(RegionInfo, long) - Method in class org.apache.hadoop.hbase.quotas.RegionSizeStoreImpl
- put(Field, Object) - Method in class org.apache.hadoop.hbase.hbtop.Record.Builder
- put(Field, FieldValue) - Method in class org.apache.hadoop.hbase.hbtop.Record.Builder
- put(Field, FieldValue) - Method in class org.apache.hadoop.hbase.hbtop.Record
- put(Record.Entry) - Method in class org.apache.hadoop.hbase.hbtop.Record.Builder
- put(CallRunner) - Method in class org.apache.hadoop.hbase.ipc.AdaptiveLifoCoDelCallQueue
- put(Cluster, String, String, byte[]) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Send a PUT request
- put(Cluster, String, String, byte[], Header) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Send a PUT request
- put(Cluster, String, Header[], byte[]) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Send a PUT request
- put(CellSetModel, UriInfo) - Method in class org.apache.hadoop.hbase.rest.RowResource
- put(NamespacesInstanceModel, UriInfo) - Method in class org.apache.hadoop.hbase.rest.NamespacesInstanceResource
-
Build a response for PUT alter namespace with properties specified.
- put(ScannerModel, UriInfo) - Method in class org.apache.hadoop.hbase.rest.ScannerResource
- put(TableSchemaModel, UriInfo) - Method in class org.apache.hadoop.hbase.rest.SchemaResource
- put(T, T) - Method in class org.apache.hadoop.hbase.regionserver.CellFlatMap
- org.apache.hadoop.hbase.client.Put - Class in org.apache.hadoop.hbase.client
-
Used to perform Put operations for a single row.
- Put - Enum constant in enum class org.apache.hadoop.hbase.Cell.Type
- Put - Enum constant in enum class org.apache.hadoop.hbase.KeyValue.Type
- Put(byte[]) - Constructor for class org.apache.hadoop.hbase.client.Put
-
Create a Put operation for the specified row.
- Put(byte[], boolean) - Constructor for class org.apache.hadoop.hbase.client.Put
-
Create a Put operation for an immutable row key.
- Put(byte[], int, int) - Constructor for class org.apache.hadoop.hbase.client.Put
-
We make a copy of the passed in row key to keep local.
- Put(byte[], int, int, long) - Constructor for class org.apache.hadoop.hbase.client.Put
-
We make a copy of the passed in row key to keep local.
- Put(byte[], long) - Constructor for class org.apache.hadoop.hbase.client.Put
-
Create a Put operation for the specified row, using a given timestamp.
- Put(byte[], long, boolean) - Constructor for class org.apache.hadoop.hbase.client.Put
-
Create a Put operation for an immutable row key, using a given timestamp.
- Put(byte[], long, NavigableMap<byte[], List<Cell>>) - Constructor for class org.apache.hadoop.hbase.client.Put
-
Construct the Put with user defined data.
- Put(ByteBuffer) - Constructor for class org.apache.hadoop.hbase.client.Put
- Put(ByteBuffer, long) - Constructor for class org.apache.hadoop.hbase.client.Put
- Put(Put) - Constructor for class org.apache.hadoop.hbase.client.Put
-
Copy constructor.
- PUT - Enum constant in enum class org.apache.hadoop.hbase.regionserver.Region.Operation
- PUT_BATCH_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- PUT_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- putAll(List<Put>) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
A simple version of batch put.
- putAll(Map<? extends byte[], ? extends byte[]>) - Method in class org.apache.hadoop.hbase.io.hfile.HFileInfo
- putAll(Map<? extends Field, ? extends FieldValue>) - Method in class org.apache.hadoop.hbase.hbtop.Record
- putAll(Map<? extends T, ? extends T>) - Method in class org.apache.hadoop.hbase.regionserver.CellFlatMap
- putAll(Map<Field, FieldValue>) - Method in class org.apache.hadoop.hbase.hbtop.Record.Builder
- putAllConfiguration(Map<String, String>) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeerConfigBuilder
-
Adds all of the provided "raw" configuration entries to
this
. - putAllPeerData(Map<byte[], byte[]>) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeerConfigBuilder
-
Sets all of the provided serialized peer configuration data.
- putAsShort(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Put an int value as short out to the specified byte array position.
- putAsShort(ByteBuffer, int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
- putBack(Cell) - Method in class org.apache.hadoop.hbase.rest.ResultGenerator
- putBack(Cell) - Method in class org.apache.hadoop.hbase.rest.RowResultGenerator
- putBack(Cell) - Method in class org.apache.hadoop.hbase.rest.ScannerResultGenerator
- putbackBuffer(ByteBuffer) - Method in class org.apache.hadoop.hbase.io.ByteBuffAllocator
-
Return back a ByteBuffer after its use.
- putbackBuffer(ByteBuffer) - Method in class org.apache.hadoop.hbase.io.DeallocateRewriteByteBuffAllocator
- putBigDecimal(byte[], int, BigDecimal) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Put a BigDecimal value out to the specified byte array position.
- putBinary(byte[], UriInfo, HttpHeaders) - Method in class org.apache.hadoop.hbase.rest.RowResource
- putByte(byte[], int, byte) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Write a single byte out to the specified byte array position.
- putByte(ByteBuffer, int, byte) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
- putByte(ByteBuffer, int, byte) - Static method in class org.apache.hadoop.hbase.util.UnsafeAccess
-
Put a byte value out to the specified BB position in big-endian format.
- putByteBuffer(byte[], int, ByteBuffer) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Add the whole content of the ByteBuffer to the bytes arrays.
- putBytes(byte[], int, byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Put bytes at the specified byte array position.
- putChar(int, int, char, Attributes) - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.ScreenBuffer
- org.apache.hadoop.hbase.mapreduce.PutCombiner<K> - Class in org.apache.hadoop.hbase.mapreduce
-
Combine Puts.
- PutCombiner() - Constructor for class org.apache.hadoop.hbase.mapreduce.PutCombiner
- putCompressedInt(OutputStream, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Put in buffer integer using 7 bit encoding.
- putConfiguration(String, String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeerConfigBuilder
-
Sets a "raw" configuration property for this replication peer.
- putDouble(byte[], int, double) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Put a double value out to the specified byte array position as the IEEE 754 double format.
- putFloat(byte[], int, float) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Put a float value out to the specified byte array position.
- putIfAbsent(K, V) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
- putInt(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Put an int value out to the specified byte array position.
- putInt(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.UnsafeAccess
-
Put an int value out to the specified byte array position in big-endian format.
- putInt(int) - Method in class org.apache.hadoop.hbase.nio.ByteBuff
-
Writes an int to this ByteBuff at its current position.
- putInt(int) - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
Writes an int to this MBB at its current position.
- putInt(int) - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
- putInt(int) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
Store int
val
at the next position in this range. - putInt(int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
- putInt(int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
- putInt(int, int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Store the int value at
index
- putInt(int, int) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
- putInt(int, int) - Method in class org.apache.hadoop.hbase.util.SimpleByteRange
- putInt(int, int) - Method in class org.apache.hadoop.hbase.util.SimpleMutableByteRange
- putInt(int, int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
- putInt(int, int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
- putInt(OutputStream, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Put in output stream 32 bit integer (Big Endian byte order).
- putInt(ByteBuffer, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Put an int value out to the given ByteBuffer's current position in big-endian format.
- putInt(ByteBuffer, int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
- putInt(ByteBuffer, int, int) - Static method in class org.apache.hadoop.hbase.util.UnsafeAccess
-
Put an int value out to the specified ByteBuffer offset in big-endian format.
- putLong(byte[], int, long) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Put a long value out to the specified byte array position.
- putLong(byte[], int, long) - Static method in class org.apache.hadoop.hbase.util.UnsafeAccess
-
Put a long value out to the specified byte array position in big-endian format.
- putLong(int, long) - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Store the long value at
index
- putLong(int, long) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
- putLong(int, long) - Method in class org.apache.hadoop.hbase.util.SimpleByteRange
- putLong(int, long) - Method in class org.apache.hadoop.hbase.util.SimpleMutableByteRange
- putLong(int, long) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
- putLong(int, long) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
- putLong(long) - Method in class org.apache.hadoop.hbase.nio.ByteBuff
-
Writes a long to this ByteBuff at its current position.
- putLong(long) - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
Writes a long to this MBB at its current position.
- putLong(long) - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
- putLong(long) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
Store long
val
at the next position in this range. - putLong(long) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
- putLong(long) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
- putLong(OutputStream, long, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
- putLong(ByteBuffer, int, long) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
- putLong(ByteBuffer, int, long) - Static method in class org.apache.hadoop.hbase.util.UnsafeAccess
-
Put a long value out to the specified BB position in big-endian format.
- putLong(ByteBuffer, long) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Put a long value out to the given ByteBuffer's current position in big-endian format.
- putPeerData(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeerConfigBuilder
-
Sets the serialized peer configuration data
- PUTS - Enum constant in enum class org.apache.hadoop.hbase.mapreduce.WALPlayer.Counter
-
Number of aggregated writes
- putShort(byte[], int, short) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Put a short value out to the specified byte array position.
- putShort(byte[], int, short) - Static method in class org.apache.hadoop.hbase.util.UnsafeAccess
-
Put a short value out to the specified byte array position in big-endian format.
- putShort(int, short) - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Store the short value at
index
- putShort(int, short) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
- putShort(int, short) - Method in class org.apache.hadoop.hbase.util.SimpleByteRange
- putShort(int, short) - Method in class org.apache.hadoop.hbase.util.SimpleMutableByteRange
- putShort(int, short) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
- putShort(int, short) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
- putShort(short) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
Store short
val
at the next position in this range. - putShort(short) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
- putShort(short) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
- putShort(ByteBuffer, int, short) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
- putShort(ByteBuffer, int, short) - Static method in class org.apache.hadoop.hbase.util.UnsafeAccess
-
Put a short value out to the specified BB position in big-endian format.
- putShort(ByteBuffer, short) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Put a short value out to the given ByteBuffer's current position in big-endian format.
- org.apache.hadoop.hbase.mapreduce.PutSortReducer - Class in org.apache.hadoop.hbase.mapreduce
-
Emits sorted Puts.
- PutSortReducer() - Constructor for class org.apache.hadoop.hbase.mapreduce.PutSortReducer
- putsToMetaTable(Connection, List<Put>) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Put the passed
ps
to thehbase:meta
table. - putString(int, int, String, Attributes) - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.ScreenBuffer
- putVLong(int, long) - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Store the long value at
index
as a VLong - putVLong(int, long) - Method in class org.apache.hadoop.hbase.util.SimpleByteRange
- putVLong(int, long) - Method in class org.apache.hadoop.hbase.util.SimpleMutableByteRange
- putVLong(int, long) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
- putVLong(int, long) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
- putVLong(long) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
Store the long
val
at the next position as a VLong - putVLong(long) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
- putVLong(long) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
Q
- qLength - Variable in class org.apache.hadoop.hbase.ExtendedCellBuilderImpl
- qOffset - Variable in class org.apache.hadoop.hbase.ExtendedCellBuilderImpl
- qop - Variable in class org.apache.hadoop.hbase.thrift.ThriftServer
- QOS_THRESHOLD - Static variable in class org.apache.hadoop.hbase.HConstants
- org.apache.hadoop.hbase.ipc.QosPriority - Annotation Interface in org.apache.hadoop.hbase.ipc
-
Annotation which decorates RPC methods to denote the relative priority among other RPCs in the same server.
- qualifier - Variable in class org.apache.hadoop.hbase.ExtendedCellBuilderImpl
- qualifier(byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncTable.CheckAndMutateBuilder
-
Deprecated.Match a qualifier.
- qualifier(byte[]) - Method in interface org.apache.hadoop.hbase.client.Table.CheckAndMutateBuilder
-
Deprecated.Specify a column qualifer
- QUALIFIER - Enum constant in enum class org.apache.hadoop.hbase.regionserver.wal.CompressionContext.DictionaryIndex
- org.apache.hadoop.hbase.filter.QualifierFilter - Class in org.apache.hadoop.hbase.filter
-
This filter is used to filter based on the column qualifier.
- QualifierFilter(CompareOperator, ByteArrayComparable) - Constructor for class org.apache.hadoop.hbase.filter.QualifierFilter
-
Constructor.
- qualifierStartsWith(Cell, byte[]) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
Finds if the start of the qualifier part of the Cell matches
buf
- org.apache.hadoop.hbase.client.Query - Class in org.apache.hadoop.hbase.client
-
Base class for HBase read operations; e.g.
- Query() - Constructor for class org.apache.hadoop.hbase.client.Query
- queryKey(Get[], boolean, long[]) - Method in class org.apache.hadoop.hbase.util.MultiThreadedReader.HBaseReaderThread
- queryKey(Get, boolean, long) - Method in class org.apache.hadoop.hbase.util.MultiThreadedReader.HBaseReaderThread
- queryKey(Get, boolean, long) - Method in class org.apache.hadoop.hbase.util.MultiThreadedReaderWithACL.HBaseReaderThreadWithACL
- QUEUE_CALL_TIME_DESC - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
- QUEUE_CALL_TIME_NAME - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
- QUEUE_FAMILY - Static variable in class org.apache.hadoop.hbase.replication.TableReplicationQueueStorage
- QUEUE_MAX_CALL_DELAY_CONF_KEY - Static variable in class org.apache.hadoop.hbase.ipc.RpcExecutor
-
max delay in msec used to bound the de-prioritized requests
- QUEUE_SIZE_DESC - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
- QUEUE_SIZE_NAME - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
- org.apache.hadoop.hbase.ipc.QueueBalancer - Interface in org.apache.hadoop.hbase.ipc
-
Interface for balancing requests across IPC queues
- queuedAndProcessedCall(int) - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
- queuedAndProcessedCall(int) - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceImpl
- queueIncrement(TIncrement) - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
- queueIncrements(List<TIncrement>) - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
- queues - Variable in class org.apache.hadoop.hbase.ipc.RpcExecutor
- queueSize - Variable in class org.apache.hadoop.hbase.ipc.FifoRpcScheduler
- queuesZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZNodePaths
- QUORUM_ADDRESS - Static variable in class org.apache.hadoop.hbase.mapreduce.TableOutputFormat
-
Deprecated.Since 3.0.0, will be removed in 4.0.0. Use
TableOutputFormat.OUTPUT_CLUSTER
to specify the peer cluster instead. - QUORUM_PORT - Static variable in class org.apache.hadoop.hbase.mapreduce.TableOutputFormat
-
Deprecated.Since 3.0.0, will be removed in 4.0.0. You do not need to use this way for specifying configurations any more, you can specify any configuration with the connection uri's queries specified by the
TableOutputFormat.OUTPUT_CLUSTER
parameter. - QUOTA_CONF_KEY - Static variable in class org.apache.hadoop.hbase.quotas.QuotaUtil
- QUOTA_DEFAULT_USER_MACHINE_READ_NUM - Static variable in class org.apache.hadoop.hbase.quotas.QuotaUtil
- QUOTA_DEFAULT_USER_MACHINE_READ_SIZE - Static variable in class org.apache.hadoop.hbase.quotas.QuotaUtil
- QUOTA_DEFAULT_USER_MACHINE_REQUEST_NUM - Static variable in class org.apache.hadoop.hbase.quotas.QuotaUtil
- QUOTA_DEFAULT_USER_MACHINE_REQUEST_SIZE - Static variable in class org.apache.hadoop.hbase.quotas.QuotaUtil
- QUOTA_DEFAULT_USER_MACHINE_WRITE_NUM - Static variable in class org.apache.hadoop.hbase.quotas.QuotaUtil
- QUOTA_DEFAULT_USER_MACHINE_WRITE_SIZE - Static variable in class org.apache.hadoop.hbase.quotas.QuotaUtil
- QUOTA_FAMILY_INFO - Static variable in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
- QUOTA_FAMILY_USAGE - Static variable in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
- QUOTA_NAMESPACE_ROW_KEY_PREFIX - Static variable in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
- QUOTA_OBSERVER_CHORE_TIME_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterQuotaSource
- QUOTA_OBSERVER_CHORE_TIME_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterQuotaSource
- QUOTA_POLICY_COLUMN - Static variable in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
- QUOTA_QUALIFIER_POLICY - Static variable in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
- QUOTA_QUALIFIER_SETTINGS - Static variable in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
- QUOTA_QUALIFIER_SETTINGS_PREFIX - Static variable in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
- QUOTA_RATE_LIMITER_CONF_KEY - Static variable in class org.apache.hadoop.hbase.quotas.RateLimiter
- QUOTA_REGION_SERVER_ROW_KEY - Static variable in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
- QUOTA_REGION_SERVER_ROW_KEY_PREFIX - Static variable in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
- QUOTA_SNAPSHOT_SIZE_QUALIFIER - Static variable in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
- QUOTA_TABLE_DESC - Static variable in class org.apache.hadoop.hbase.quotas.QuotaUtil
-
Table descriptor for Quota internal table
- QUOTA_TABLE_NAME - Static variable in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
System table for quotas
- QUOTA_TABLE_ROW_KEY_PREFIX - Static variable in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
- QUOTA_USER_REQUEST_ATTRIBUTE_OVERRIDE_KEY - Static variable in class org.apache.hadoop.hbase.quotas.QuotaCache
- QUOTA_USER_ROW_KEY_PREFIX - Static variable in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
- org.apache.hadoop.hbase.quotas.QuotaCache - Class in org.apache.hadoop.hbase.quotas
-
Cache that keeps track of the quota settings for the users and tables that are interacting with it.
- QuotaCache(RegionServerServices) - Constructor for class org.apache.hadoop.hbase.quotas.QuotaCache
- quotaExceededException() - Method in interface org.apache.hadoop.hbase.metrics.ExceptionTrackingSource
- quotaExceededException() - Method in class org.apache.hadoop.hbase.metrics.ExceptionTrackingSourceImpl
- org.apache.hadoop.hbase.quotas.QuotaExceededException - Exception in org.apache.hadoop.hbase.quotas
-
Generic quota exceeded exception
- QuotaExceededException(String) - Constructor for exception org.apache.hadoop.hbase.quotas.QuotaExceededException
- QuotaExceededException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.quotas.QuotaExceededException
- org.apache.hadoop.hbase.quotas.QuotaFilter - Class in org.apache.hadoop.hbase.quotas
-
Filter to use to filter the QuotaRetriever results.
- QuotaFilter() - Constructor for class org.apache.hadoop.hbase.quotas.QuotaFilter
- org.apache.hadoop.hbase.quotas.QuotaLimiter - Interface in org.apache.hadoop.hbase.quotas
-
Internal interface used to interact with the user/table quota.
- org.apache.hadoop.hbase.quotas.QuotaLimiterFactory - Class in org.apache.hadoop.hbase.quotas
- QuotaLimiterFactory() - Constructor for class org.apache.hadoop.hbase.quotas.QuotaLimiterFactory
- org.apache.hadoop.hbase.quotas.QuotaObserverChore - Class in org.apache.hadoop.hbase.quotas
-
Reads the currently received Region filesystem-space use reports and acts on those which violate a defined quota.
- QuotaObserverChore(HMaster, MetricsMaster) - Constructor for class org.apache.hadoop.hbase.quotas.QuotaObserverChore
- org.apache.hadoop.hbase.quotas.QuotaRetriever - Class in org.apache.hadoop.hbase.quotas
-
Scanner to iterate over the quota settings.
- QuotaRetriever(Connection) - Constructor for class org.apache.hadoop.hbase.quotas.QuotaRetriever
- QuotaRetriever(Connection, Scan) - Constructor for class org.apache.hadoop.hbase.quotas.QuotaRetriever
- QuotaRetriever(Connection, QuotaFilter) - Constructor for class org.apache.hadoop.hbase.quotas.QuotaRetriever
- org.apache.hadoop.hbase.quotas.QuotaScope - Enum Class in org.apache.hadoop.hbase.quotas
-
Describe the Scope of the quota rules.
- org.apache.hadoop.hbase.quotas.QuotaSettings - Class in org.apache.hadoop.hbase.quotas
- QuotaSettings(String, TableName, String, String) - Constructor for class org.apache.hadoop.hbase.quotas.QuotaSettings
- org.apache.hadoop.hbase.quotas.QuotaSettingsFactory - Class in org.apache.hadoop.hbase.quotas
- QuotaSettingsFactory() - Constructor for class org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
- quotasFromData(byte[]) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
- quotasFromData(byte[], int, int) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
- QuotaSnapshotSizeSerializationException(String) - Constructor for exception org.apache.hadoop.hbase.quotas.FileArchiverNotifierImpl.QuotaSnapshotSizeSerializationException
- org.apache.hadoop.hbase.quotas.QuotaSnapshotStore<T> - Interface in org.apache.hadoop.hbase.quotas
-
A common interface for computing and storing space quota observance/violation for entities.
- org.apache.hadoop.hbase.quotas.QuotaState - Class in org.apache.hadoop.hbase.quotas
-
In-Memory state of table or namespace quotas
- QuotaState() - Constructor for class org.apache.hadoop.hbase.quotas.QuotaState
- QuotaState(long) - Constructor for class org.apache.hadoop.hbase.quotas.QuotaState
- quotasToData(QuotaProtos.Quotas) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
- org.apache.hadoop.hbase.quotas.QuotaTableUtil - Class in org.apache.hadoop.hbase.quotas
-
Helper class to interact with the quota table.
- QuotaTableUtil() - Constructor for class org.apache.hadoop.hbase.quotas.QuotaTableUtil
- org.apache.hadoop.hbase.quotas.QuotaTableUtil.NamespaceQuotasVisitor - Interface in org.apache.hadoop.hbase.quotas
- org.apache.hadoop.hbase.quotas.QuotaTableUtil.QuotasVisitor - Interface in org.apache.hadoop.hbase.quotas
- org.apache.hadoop.hbase.quotas.QuotaTableUtil.TableQuotasVisitor - Interface in org.apache.hadoop.hbase.quotas
- org.apache.hadoop.hbase.quotas.QuotaTableUtil.UserQuotasVisitor - Interface in org.apache.hadoop.hbase.quotas
- org.apache.hadoop.hbase.quotas.QuotaType - Enum Class in org.apache.hadoop.hbase.quotas
-
Describe the Quota Type.
- org.apache.hadoop.hbase.quotas.QuotaUtil - Class in org.apache.hadoop.hbase.quotas
-
Helper class to interact with the quota table
- QuotaUtil() - Constructor for class org.apache.hadoop.hbase.quotas.QuotaUtil
- quoteHtmlChars(OutputStream, byte[], int, int) - Static method in class org.apache.hadoop.hbase.http.HtmlQuoting
-
Quote all of the active HTML characters in the given string as they are added to the buffer.
- quoteHtmlChars(String) - Static method in class org.apache.hadoop.hbase.http.HtmlQuoting
-
Quote the given item to make it html-safe.
- quoteOutputStream(OutputStream) - Static method in class org.apache.hadoop.hbase.http.HtmlQuoting
-
Return an output stream that quotes all of the output.
- QuotingInputFilter() - Constructor for class org.apache.hadoop.hbase.http.HttpServer.QuotingInputFilter
R
- R - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
ASCII code for 'R'
- rackManager(RackManager) - Method in class org.apache.hadoop.hbase.util.RegionMover.RegionMoverBuilder
-
Set specific rackManager implementation.
- org.apache.hadoop.hbase.master.RackManager - Class in org.apache.hadoop.hbase.master
-
Wrapper over the rack resolution utility in Hadoop.
- RackManager() - Constructor for class org.apache.hadoop.hbase.master.RackManager
- RackManager(Configuration) - Constructor for class org.apache.hadoop.hbase.master.RackManager
- random(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Fill given array with random bytes.
- random(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Fill given array with random bytes at the specified position.
- org.apache.hadoop.hbase.util.Random64 - Class in org.apache.hadoop.hbase.util
-
An instance of this class is used to generate a stream of pseudorandom numbers.
- Random64() - Constructor for class org.apache.hadoop.hbase.util.Random64
- Random64(long) - Constructor for class org.apache.hadoop.hbase.util.Random64
- randomAssignment(RegionInfo, List<ServerName>) - Method in class org.apache.hadoop.hbase.favored.FavoredNodeLoadBalancer
- randomAssignment(RegionInfo, List<ServerName>) - Method in interface org.apache.hadoop.hbase.master.LoadBalancer
-
Get a random region server from the list
- randomAssignment(RegionInfo, List<ServerName>) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupBasedLoadBalancer
- org.apache.hadoop.hbase.util.RandomDistribution - Class in org.apache.hadoop.hbase.util
-
A class that generates random numbers that follow some distribution.
- RandomDistribution() - Constructor for class org.apache.hadoop.hbase.util.RandomDistribution
- org.apache.hadoop.hbase.util.RandomDistribution.Binomial - Class in org.apache.hadoop.hbase.util
-
Binomial distribution.
- org.apache.hadoop.hbase.util.RandomDistribution.DiscreteRNG - Interface in org.apache.hadoop.hbase.util
-
Interface for discrete (integer) random distributions.
- org.apache.hadoop.hbase.util.RandomDistribution.Flat - Class in org.apache.hadoop.hbase.util
-
P(i)=1/(max-min)
- org.apache.hadoop.hbase.util.RandomDistribution.Zipf - Class in org.apache.hadoop.hbase.util
-
Zipf distribution.
- randomFreePort() - Static method in class org.apache.hadoop.hbase.HBaseCommonTestingUtility
-
Deprecated.
- randomFreePort() - Static method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- RandomizedMatrix(int, int) - Constructor for class org.apache.hadoop.hbase.master.RegionPlacementMaintainer.RandomizedMatrix
-
Create a randomization scheme for a matrix of a given size.
- randomMultiCastAddress() - Static method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- org.apache.hadoop.hbase.ipc.RandomQueueBalancer - Class in org.apache.hadoop.hbase.ipc
-
Queue balancer that just randomly selects a queue in the range [0, num queues).
- RandomQueueBalancer(Configuration, String, List<BlockingQueue<CallRunner>>) - Constructor for class org.apache.hadoop.hbase.ipc.RandomQueueBalancer
- org.apache.hadoop.hbase.filter.RandomRowFilter - Class in org.apache.hadoop.hbase.filter
-
A filter that includes rows based on a chance.
- RandomRowFilter(float) - Constructor for class org.apache.hadoop.hbase.filter.RandomRowFilter
-
Create a new filter with a specified chance for a row to be included.
- RANGESMATCHED - Enum constant in enum class org.apache.hadoop.hbase.mapreduce.SyncTable.SyncMapper.Counter
- RANGESNOTMATCHED - Enum constant in enum class org.apache.hadoop.hbase.mapreduce.SyncTable.SyncMapper.Counter
- RATE_LIMITER_REFILL_INTERVAL_MS - Static variable in class org.apache.hadoop.hbase.quotas.FixedIntervalRateLimiter
-
The FixedIntervalRateLimiter can be harsh from a latency/backoff perspective, which makes it difficult to fully and consistently utilize a quota allowance.
- org.apache.hadoop.hbase.quotas.RateLimiter - Class in org.apache.hadoop.hbase.quotas
-
Simple rate limiter.
- RateLimiter() - Constructor for class org.apache.hadoop.hbase.quotas.RateLimiter
- RAW_SCAN - Static variable in class org.apache.hadoop.hbase.mapreduce.ExportUtils
- org.apache.hadoop.hbase.types.RawByte - Class in org.apache.hadoop.hbase.types
-
An
DataType
for interacting with values encoded usingBytes.putByte(byte[], int, byte)
. - RawByte() - Constructor for class org.apache.hadoop.hbase.types.RawByte
- org.apache.hadoop.hbase.types.RawBytes - Class in org.apache.hadoop.hbase.types
-
An
DataType
for interacting with variable-length values encoded usingBytes.putBytes(byte[], int, byte[], int, int)
. - RawBytes() - Constructor for class org.apache.hadoop.hbase.types.RawBytes
-
Deprecated.since 3.0.0 and will be removed in 4.0.0
- RawBytes(Order) - Constructor for class org.apache.hadoop.hbase.types.RawBytes
-
Creates a new
DataType
with variable-length values. - org.apache.hadoop.hbase.types.RawBytesFixedLength - Class in org.apache.hadoop.hbase.types
-
An
DataType
that encodes fixed-length values encoded usingBytes.putBytes(byte[], int, byte[], int, int)
. - RawBytesFixedLength(int) - Constructor for class org.apache.hadoop.hbase.types.RawBytesFixedLength
-
Create a
RawBytesFixedLength
of the specifiedlength
. - RawBytesFixedLength(Order, int) - Constructor for class org.apache.hadoop.hbase.types.RawBytesFixedLength
-
Create a
RawBytesFixedLength
using the specifiedorder
andlength
. - org.apache.hadoop.hbase.types.RawBytesTerminated - Class in org.apache.hadoop.hbase.types
-
An
DataType
that encodes variable-length values encoded usingBytes.putBytes(byte[], int, byte[], int, int)
. - RawBytesTerminated(byte[]) - Constructor for class org.apache.hadoop.hbase.types.RawBytesTerminated
-
Create a
RawBytesTerminated
using the specified terminator. - RawBytesTerminated(String) - Constructor for class org.apache.hadoop.hbase.types.RawBytesTerminated
-
Create a
RawBytesTerminated
using the specified terminator. - RawBytesTerminated(Order, byte[]) - Constructor for class org.apache.hadoop.hbase.types.RawBytesTerminated
-
Create a
RawBytesTerminated
using the specified terminator andorder
. - RawBytesTerminated(Order, String) - Constructor for class org.apache.hadoop.hbase.types.RawBytesTerminated
-
Create a
RawBytesTerminated
using the specified terminator andorder
. - org.apache.hadoop.hbase.RawCell - Interface in org.apache.hadoop.hbase
-
An extended version of Cell that allows CPs manipulate Tags.
- org.apache.hadoop.hbase.RawCellBuilder - Interface in org.apache.hadoop.hbase
-
Allows creating a cell with
Tag
An instance of this type can be acquired by using RegionCoprocessorEnvironment#getCellBuilder (for prod code) andRawCellBuilderFactory
(for unit tests). - org.apache.hadoop.hbase.RawCellBuilderFactory - Class in org.apache.hadoop.hbase
-
Factory for creating cells for CPs.
- rawCells() - Method in class org.apache.hadoop.hbase.client.Result
-
Return the array of Cells backing this Result instance.
- org.apache.hadoop.hbase.types.RawDouble - Class in org.apache.hadoop.hbase.types
-
An
DataType
for interacting with values encoded usingBytes.putDouble(byte[], int, double)
. - RawDouble() - Constructor for class org.apache.hadoop.hbase.types.RawDouble
- org.apache.hadoop.hbase.types.RawFloat - Class in org.apache.hadoop.hbase.types
-
An
DataType
for interacting with values encoded usingBytes.putFloat(byte[], int, float)
. - RawFloat() - Constructor for class org.apache.hadoop.hbase.types.RawFloat
- org.apache.hadoop.hbase.types.RawInteger - Class in org.apache.hadoop.hbase.types
-
An
DataType
for interacting with values encoded usingBytes.putInt(byte[], int, int)
. - RawInteger() - Constructor for class org.apache.hadoop.hbase.types.RawInteger
- org.apache.hadoop.hbase.types.RawLong - Class in org.apache.hadoop.hbase.types
-
An
DataType
for interacting with values encoded usingBytes.putLong(byte[], int, long)
. - RawLong() - Constructor for class org.apache.hadoop.hbase.types.RawLong
- org.apache.hadoop.hbase.regionserver.querymatcher.RawScanQueryMatcher - Class in org.apache.hadoop.hbase.regionserver.querymatcher
-
Query matcher for raw scan.
- RawScanQueryMatcher(Scan, ScanInfo, ColumnTracker, boolean, long, long) - Constructor for class org.apache.hadoop.hbase.regionserver.querymatcher.RawScanQueryMatcher
- org.apache.hadoop.hbase.types.RawShort - Class in org.apache.hadoop.hbase.types
-
An
DataType
for interacting with values encoded usingBytes.putShort(byte[], int, short)
. - RawShort() - Constructor for class org.apache.hadoop.hbase.types.RawShort
- org.apache.hadoop.hbase.types.RawString - Class in org.apache.hadoop.hbase.types
-
An
DataType
for interacting with values encoded usingBytes.toBytes(String)
. - RawString() - Constructor for class org.apache.hadoop.hbase.types.RawString
-
Deprecated.since 3.0.0 and will be removed in 4.0.0
- RawString(Order) - Constructor for class org.apache.hadoop.hbase.types.RawString
-
Creates a new
DataType
for interacting with values encoded usingBytes.toBytes(String)
. - org.apache.hadoop.hbase.types.RawStringFixedLength - Class in org.apache.hadoop.hbase.types
-
An
DataType
that encodes fixed-length values encoded usingBytes.toBytes(String)
. - RawStringFixedLength(int) - Constructor for class org.apache.hadoop.hbase.types.RawStringFixedLength
-
Create a
RawStringFixedLength
of the specifiedlength
. - RawStringFixedLength(Order, int) - Constructor for class org.apache.hadoop.hbase.types.RawStringFixedLength
-
Create a
RawStringFixedLength
using the specifiedorder
andlength
. - org.apache.hadoop.hbase.types.RawStringTerminated - Class in org.apache.hadoop.hbase.types
-
An
DataType
that encodes variable-length values encoded usingBytes.toBytes(String)
. - RawStringTerminated(byte[]) - Constructor for class org.apache.hadoop.hbase.types.RawStringTerminated
-
Create a
RawStringTerminated
using the specified terminator. - RawStringTerminated(String) - Constructor for class org.apache.hadoop.hbase.types.RawStringTerminated
-
Create a
RawStringTerminated
using the specified terminator. - RawStringTerminated(Order, byte[]) - Constructor for class org.apache.hadoop.hbase.types.RawStringTerminated
-
Create a
RawStringTerminated
using the specified terminator andorder
. - RawStringTerminated(Order, String) - Constructor for class org.apache.hadoop.hbase.types.RawStringTerminated
-
Create a
RawStringTerminated
using the specified terminator andorder
. - reachWALEditsStopOffset(long) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractProtobufWALReader
- read() - Method in class org.apache.hadoop.hbase.io.ByteBufferInputStream
-
Reads the next byte of data from this input stream.
- read() - Method in class org.apache.hadoop.hbase.io.ByteBuffInputStream
-
Reads the next byte of data from this input stream.
- read() - Method in class org.apache.hadoop.hbase.io.FileLink.FileLinkInputStream
- read() - Method in class org.apache.hadoop.hbase.io.hadoopbackport.ThrottledInputStream
- read() - Method in class org.apache.hadoop.hbase.util.RotateFile
-
Reads the content of the rotate file by selecting the winner file based on the timestamp of the data inside the files.
- read(byte[]) - Method in class org.apache.hadoop.hbase.io.FileLink.FileLinkInputStream
- read(byte[]) - Method in class org.apache.hadoop.hbase.io.hadoopbackport.ThrottledInputStream
- read(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.ByteBufferInputStream
-
Reads up to next
len
bytes of data from buffer into passed array(starting from given offset). - read(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.ByteBuffInputStream
-
Reads up to next
len
bytes of data from buffer into passed array(starting from given offset). - read(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.FileLink.FileLinkInputStream
- read(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.hadoopbackport.ThrottledInputStream
- read(long, byte[], int, int) - Method in class org.apache.hadoop.hbase.io.FileLink.FileLinkInputStream
- read(long, byte[], int, int) - Method in class org.apache.hadoop.hbase.io.hadoopbackport.ThrottledInputStream
-
Read bytes starting from the specified position.
- read(long, ByteBuff) - Method in class org.apache.hadoop.hbase.util.ByteBufferArray
-
Transfers bytes from this buffers array into the given destination
ByteBuff
- read(DataInput) - Static method in enum class org.apache.hadoop.hbase.security.AuthMethod
-
Read from in
- read(DataInputStream) - Static method in enum class org.apache.hadoop.hbase.io.hfile.BlockType
- read(FileChannel, long) - Method in class org.apache.hadoop.hbase.nio.ByteBuff
-
Reads bytes from FileChannel into this ByteBuff
- read(FileChannel, long) - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
- read(FileChannel, long) - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
- read(ReadableByteChannel) - Method in class org.apache.hadoop.hbase.nio.ByteBuff
-
Reads bytes from the given channel into this ByteBuf.
- read(ReadableByteChannel) - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
- read(ReadableByteChannel) - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
- read(ReadableByteChannel, ByteBuffer, long, ByteBuff.ChannelReader) - Static method in class org.apache.hadoop.hbase.nio.ByteBuff
- read(Configuration, Path) - Static method in class org.apache.hadoop.hbase.mapreduce.HashTable.TableHash
- read(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.io.Reference
-
Read a Reference from FileSystem.
- read(ByteBuff) - Static method in enum class org.apache.hadoop.hbase.io.hfile.BlockType
- READ_CAPACITY_UNIT - Enum constant in enum class org.apache.hadoop.hbase.quotas.ThrottleType
-
Throttling based on the read data capacity unit
- READ_CAPACITY_UNIT_CONF_KEY - Static variable in class org.apache.hadoop.hbase.quotas.QuotaUtil
- READ_COMMITTED - Enum constant in enum class org.apache.hadoop.hbase.client.IsolationLevel
- READ_NUMBER - Enum constant in enum class org.apache.hadoop.hbase.quotas.ThrottleType
-
Throttling based on the number of read requests per time-unit
- READ_OPERATION_LATENCY_DESC - Static variable in interface org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSource
- READ_OPERATION_LATENCY_NAME - Static variable in interface org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSource
- READ_QUEUE_DESC - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
- READ_QUEUE_NAME - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
- READ_REQUEST_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- READ_REQUEST_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- READ_REQUEST_COUNT_PER_SECOND - Enum constant in enum class org.apache.hadoop.hbase.hbtop.field.Field
- READ_REQUEST_RATE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- READ_REQUEST_RATE_PER_SECOND - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- READ_SIZE - Enum constant in enum class org.apache.hadoop.hbase.quotas.ThrottleType
-
Throttling based on the read data size
- READ_TIMEOUT - Static variable in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputHelper
- READ_TIMEOUT_OPTION - Static variable in class org.apache.hadoop.hbase.thrift.Constants
- READ_UNCOMMITTED - Enum constant in enum class org.apache.hadoop.hbase.client.IsolationLevel
- readAllVersions() - Method in class org.apache.hadoop.hbase.client.Get
-
Get all available versions.
- readAllVersions() - Method in class org.apache.hadoop.hbase.client.ImmutableScan
- readAllVersions() - Method in class org.apache.hadoop.hbase.client.Scan
-
Get all available versions.
- readAllVersions() - Method in interface org.apache.hadoop.hbase.regionserver.ScanOptions
- readAndCheck(DataInputStream) - Method in enum class org.apache.hadoop.hbase.io.hfile.BlockType
-
Reads a magic record of the length
BlockType.MAGIC_LENGTH
from the given stream and expects it to match this block type. - readAndCheck(ByteBuffer) - Method in enum class org.apache.hadoop.hbase.io.hfile.BlockType
-
Reads a magic record of the length
BlockType.MAGIC_LENGTH
from the given byte buffer and expects it to match this block type. - readAndUpdateNewBlock(long) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
- readAsInt(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Converts a byte array to an int value
- readAsInt(ByteBuffer, int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Converts a ByteBuffer to an int value
- readAsVLong(byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Reads a zero-compressed encoded long from input buffer and returns it.
- readAvailable - Variable in class org.apache.hadoop.hbase.quotas.DefaultOperationQuota
- readBlock(long, long, boolean, boolean, boolean, boolean, BlockType, DataBlockEncoding) - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.CachingBlockReader
-
Read in a file block.
- readBlock(long, long, boolean, boolean, boolean, boolean, BlockType, DataBlockEncoding) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
- readBlock(long, long, boolean, boolean, boolean, boolean, BlockType, DataBlockEncoding, boolean) - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.CachingBlockReader
- readBlock(long, long, boolean, boolean, boolean, boolean, BlockType, DataBlockEncoding, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
- readByte(InputStream) - Static method in class org.apache.hadoop.hbase.io.util.StreamUtils
-
Read a byte from the given stream using the read method, and throw EOFException if it returns -1, like the implementation in
DataInputStream
. - readByteArray(DataInput) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Read byte-array written with a WritableableUtils.vint prefix.
- readByteArrayThrowsRuntime(DataInput) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Read byte-array written with a WritableableUtils.vint prefix.
- readCapacityUnitConsumed - Variable in class org.apache.hadoop.hbase.quotas.DefaultOperationQuota
- readCapacityUnitDiff - Variable in class org.apache.hadoop.hbase.quotas.DefaultOperationQuota
- ReadCapacityUnitExceeded - Enum constant in enum class org.apache.hadoop.hbase.quotas.RpcThrottlingException.Type
- readCell(ExtendedCell, boolean) - Method in class org.apache.hadoop.hbase.mob.MobFile
-
Reads a cell from the mob file.
- readCell(ExtendedCell, boolean, long) - Method in class org.apache.hadoop.hbase.mob.MobFile
-
Reads a cell from the mob file.
- readClusterIdZNode(ZKWatcher) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKClusterId
- readCompressedInt(InputStream) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Read integer from stream coded in 7 bits and increment position.
- readCompressedInt(ByteBuffer) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Read integer from buffer coded in 7 bits and increment position.
- readCompressedInt(ByteBuff) - Static method in class org.apache.hadoop.hbase.nio.ByteBuff
-
Read integer from ByteBuff coded in 7 bits and increment position.
- readConsumed - Variable in class org.apache.hadoop.hbase.quotas.DefaultOperationQuota
- readDiff - Variable in class org.apache.hadoop.hbase.quotas.DefaultOperationQuota
- reader - Variable in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
- reader - Variable in class org.apache.hadoop.hbase.regionserver.StoreFileReader
- org.apache.hadoop.hbase.io.hfile.ReaderContext - Class in org.apache.hadoop.hbase.io.hfile
-
Carries the information on some of the meta data about the HFile Reader
- ReaderContext(Path, FSDataInputStreamWrapper, long, HFileSystem, boolean, ReaderContext.ReaderType) - Constructor for class org.apache.hadoop.hbase.io.hfile.ReaderContext
- org.apache.hadoop.hbase.io.hfile.ReaderContext.ReaderType - Enum Class in org.apache.hadoop.hbase.io.hfile
- org.apache.hadoop.hbase.io.hfile.ReaderContextBuilder - Class in org.apache.hadoop.hbase.io.hfile
-
A builder that helps in building up the ReaderContext
- ReaderContextBuilder() - Constructor for class org.apache.hadoop.hbase.io.hfile.ReaderContextBuilder
- readerId - Variable in class org.apache.hadoop.hbase.util.MultiThreadedReader.HBaseReaderThread
- readerPath - Variable in class org.apache.hadoop.hbase.io.FSDataInputStreamWrapper
- readers - Variable in class org.apache.hadoop.hbase.util.MultiThreadedReader
- readerThreads - Variable in class org.apache.hadoop.hbase.util.LoadTestTool
- ReadExampleCallable(Connection, TableName) - Constructor for class org.apache.hadoop.hbase.client.example.MultiThreadedClientExample.ReadExampleCallable
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.io.Reference
-
Deprecated.Writables are going away. Use the pb serialization methods instead. Remove in a release after 0.96 goes out. This is here only to migrate old Reference files written with Writables before 0.96.
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.mapred.TableSnapshotInputFormat.TableSnapshotRegionSplit
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.mapred.TableSplit
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.mapreduce.Import.CellWritableComparable
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormat.TableSnapshotRegionSplit
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.InputSplit
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
-
Reads the values of each field.
- readFieldsFromPb(WALProtos.WALKey, WALCellCodec.ByteStringUncompressor) - Method in class org.apache.hadoop.hbase.wal.WALKeyImpl
- readFromCells(Codec.Decoder, int) - Method in class org.apache.hadoop.hbase.wal.WALEdit
-
Reads WALEdit from cells.
- readFromStream(FSDataInputStream, long) - Static method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
Reads a file trailer from the given file.
- readFully(long, byte[]) - Method in class org.apache.hadoop.hbase.io.FileLink.FileLinkInputStream
- readFully(long, byte[], int, int) - Method in class org.apache.hadoop.hbase.io.FileLink.FileLinkInputStream
- readFully(ByteBuff, FSDataInputStream, int) - Static method in class org.apache.hadoop.hbase.io.util.BlockIOUtils
-
Read length bytes into ByteBuffers directly.
- readFullyWithHeapBuffer(InputStream, ByteBuff, int) - Static method in class org.apache.hadoop.hbase.io.util.BlockIOUtils
-
Copying bytes from InputStream to
ByteBuff
by using an temporary heap byte[] (default size is 1024 now). - readHeader(FSDataInputStream) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractProtobufWALReader
- readKeyValueLen() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
- readLock() - Method in class org.apache.hadoop.hbase.regionserver.StoreEngine
-
Acquire read lock of this store.
- readLong(InputStream) - Static method in class org.apache.hadoop.hbase.io.util.StreamUtils
- readLong(InputStream, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Read long which was written to fitInBytes bytes and increment position.
- readLong(ByteBuffer, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Read long which was written to fitInBytes bytes and increment position.
- readLong(ByteBuff, int) - Static method in class org.apache.hadoop.hbase.nio.ByteBuff
-
Read long which was written to fitInBytes bytes and increment position.
- readMvccVersion(int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
-
Read mvcc.
- readMyEphemeralNodeOnDisk() - Static method in class org.apache.hadoop.hbase.ZNodeClearer
-
read the content of znode file, expects a single line.
- readNext(TNode) - Static method in class org.apache.hadoop.hbase.util.AvlUtil.AvlIterableList
-
Return the successor of the current node
- readNextDataBlock() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
-
Scans blocks in the "scanned" section of the
HFile
until the next data block is found. - READONLY - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
Used by rest interface to access this metadata attribute which denotes if the table is Read Only.
- READONLY_LOGGERS_CONF_KEY - Static variable in class org.apache.hadoop.hbase.http.log.LogLevel
- READONLY_OPTION - Static variable in class org.apache.hadoop.hbase.thrift.Constants
- org.apache.hadoop.hbase.util.ReadOnlyByteRangeException - Exception in org.apache.hadoop.hbase.util
-
Exception thrown when a read only byte range is modified
- ReadOnlyByteRangeException() - Constructor for exception org.apache.hadoop.hbase.util.ReadOnlyByteRangeException
- org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration - Class in org.apache.hadoop.hbase.coprocessor
-
Wraps a Configuration to make it read-only.
- ReadOnlyConfiguration(Configuration) - Constructor for class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
- org.apache.hadoop.hbase.zookeeper.ReadOnlyZKClient - Class in org.apache.hadoop.hbase.zookeeper
-
A very simple read only zookeeper implementation without watcher support.
- ReadOnlyZKClient(Configuration, HashedWheelTimer) - Constructor for class org.apache.hadoop.hbase.zookeeper.ReadOnlyZKClient
- org.apache.hadoop.hbase.regionserver.ReadPointCalculationLock - Class in org.apache.hadoop.hbase.regionserver
-
Lock to manage concurrency between
RegionScanner
andHRegion.getSmallestReadPoint()
. - org.apache.hadoop.hbase.regionserver.ReadPointCalculationLock.LockType - Enum Class in org.apache.hadoop.hbase.regionserver
- readPrev(TNode) - Static method in class org.apache.hadoop.hbase.util.AvlUtil.AvlIterableList
-
Return the predecessor of the current node
- readPt - Variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
- readRawVarint32(byte[], int) - Static method in class org.apache.hadoop.hbase.io.util.StreamUtils
-
Reads a varInt value stored in an array.
- readRawVarint32(InputStream) - Static method in class org.apache.hadoop.hbase.io.util.StreamUtils
- readRawVarint32(ByteBuffer, int) - Static method in class org.apache.hadoop.hbase.io.util.StreamUtils
- readRawVarint32(ByteBuff) - Static method in class org.apache.hadoop.hbase.io.util.StreamUtils
- readReference(Path) - Method in interface org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileTracker
-
Reads the reference file from the given path.
- ReadSizeExceeded - Enum constant in enum class org.apache.hadoop.hbase.quotas.RpcThrottlingException.Type
- readSnapshotInfo(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
Read in the
SnapshotProtos.SnapshotDescription
stored for the snapshot in the passed directory - readStringFixedSize(DataInput, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Reads a fixed-size field and interprets it as a string padded with zeros.
- readTimestamp(ByteBuffer) - Method in class org.apache.hadoop.hbase.io.encoding.DiffKeyDeltaEncoder.DiffCompressionState
- readTO - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
- readTrailer(FSDataInputStream, FileStatus) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractProtobufWALReader
- readUnlock() - Method in class org.apache.hadoop.hbase.regionserver.StoreEngine
-
Release read lock of this store.
- readVersions(int) - Method in class org.apache.hadoop.hbase.client.Get
-
Get up to the specified number of versions of each column.
- readVersions(int) - Method in class org.apache.hadoop.hbase.client.ImmutableScan
- readVersions(int) - Method in class org.apache.hadoop.hbase.client.Scan
-
Get up to the specified number of versions of each column.
- readVIntValuePart(Tag, int) - Static method in class org.apache.hadoop.hbase.TagUtil
-
Reads an int value stored as a VInt at tag's given offset.
- readVLong(ByteBuffer) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Similar to
WritableUtils.readVLong(DataInput)
but reads from aByteBuffer
. - readVLong(ByteBuff) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Similar to
WritableUtils.readVLong(java.io.DataInput)
but reads from aByteBuff
. - readWithExtra(ByteBuff, FSDataInputStream, int, int) - Static method in class org.apache.hadoop.hbase.io.util.BlockIOUtils
-
Read bytes into ByteBuffers directly, those buffers either contains the extraLen bytes or only contains necessaryLen bytes, which depends on how much bytes do the last time we read.
- readZKNodes(Configuration) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKServerTool
- reallocate(int, int) - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.ScreenBuffer
- realSeekDone() - Method in interface org.apache.hadoop.hbase.regionserver.KeyValueScanner
-
We optimize our store scanners by checking the most recent store file first, so we sometimes pretend we have done a seek but delay it until the store scanner bubbles up to the top of the key-value heap.
- realSeekDone() - Method in class org.apache.hadoop.hbase.regionserver.NonLazyKeyValueScanner
- realSeekDone() - Method in class org.apache.hadoop.hbase.regionserver.SegmentScanner
-
This scanner is working solely on the in-memory MemStore and doesn't work on store files, MutableCellSetSegmentScanner always does the seek, therefore always returning true.
- realSeekDone() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
- receive(ForeignException) - Method in class org.apache.hadoop.hbase.errorhandling.ForeignExceptionDispatcher
- receive(ForeignException) - Method in interface org.apache.hadoop.hbase.errorhandling.ForeignExceptionListener
-
Receive a ForeignException.
- RECEIVED_BYTES_DESC - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
- RECEIVED_BYTES_NAME - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
- receivedBytes(int) - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
- receivedBytes(int) - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceImpl
- receivedRequest(long) - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
- receivedRequest(long) - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceImpl
- receiveTime - Variable in class org.apache.hadoop.hbase.ipc.ServerCall
- reclaimMemStoreMemory() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreFlusher
-
Check if the regionserver's memstore memory usage is greater than the limit.
- recommissionRegionServer(ServerName, List<byte[]>) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Remove decommission marker from a region server to allow regions assignments.
- recommissionRegionServer(ServerName, List<byte[]>) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Remove decommission marker from a region server to allow regions assignments.
- recommissionRegionServer(ServerName, List<byte[]>) - Method in class org.apache.hadoop.hbase.master.HMaster
-
Remove decommission marker (previously called 'draining') from a region server to allow regions assignments.
- recommissionRegionServer(RpcController, MasterProtos.RecommissionRegionServerRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- reconnectAfterExpiration() - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
- reconnectAfterExpiration() - Method in class org.apache.hadoop.hbase.zookeeper.ZKWatcher
- org.apache.hadoop.hbase.hbtop.Record - Class in org.apache.hadoop.hbase.hbtop
-
Represents a record of the metrics in the top screen.
- org.apache.hadoop.hbase.hbtop.Record.Builder - Class in org.apache.hadoop.hbase.hbtop
- org.apache.hadoop.hbase.hbtop.Record.Entry - Class in org.apache.hadoop.hbase.hbtop
- recordBlockSize(IntConsumer) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
- recordBlockSize(IntConsumer) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
-
Record the size of the current block in bytes, passing as an argument to the blockSizeConsumer.
- recordBlockSize(IntConsumer) - Method in class org.apache.hadoop.hbase.regionserver.KeyValueHeap
- recordBlockSize(IntConsumer) - Method in interface org.apache.hadoop.hbase.regionserver.KeyValueScanner
-
Record the size of the current block in bytes, passing as an argument to the blockSizeConsumer.
- recordBlockSize(IntConsumer) - Method in class org.apache.hadoop.hbase.regionserver.NonLazyKeyValueScanner
- recordBlockSize(IntConsumer) - Method in class org.apache.hadoop.hbase.regionserver.SegmentScanner
- recordBlockSize(IntConsumer) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
- org.apache.hadoop.hbase.hbtop.RecordFilter - Class in org.apache.hadoop.hbase.hbtop
-
Represents a filter that's filtering the metric
Record
s. - org.apache.hadoop.hbase.hbtop.RecordFilter.FilterBuilder - Class in org.apache.hadoop.hbase.hbtop
- RECORDING_LOCK - Enum constant in enum class org.apache.hadoop.hbase.regionserver.ReadPointCalculationLock.LockType
- RecordReader() - Constructor for class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.RecordReader
- recordReadOperationLatency(long) - Method in interface org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSource
-
Record the latency incurred for read operations.
- recordReadOperationLatency(long) - Method in class org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSourceImpl
- recordSyncOperationLatency(long) - Method in interface org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSource
-
Record the latency incurred for sync operations.
- recordSyncOperationLatency(long) - Method in class org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSourceImpl
- recordWriteOperationLatency(long) - Method in interface org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSource
-
Record the latency incurred for write operations.
- recordWriteOperationLatency(long) - Method in class org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSourceImpl
- org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper - Class in org.apache.hadoop.hbase.zookeeper
-
A zookeeper that can handle 'recoverable' errors.
- recoverAndClose(CancelableProgressable) - Method in interface org.apache.hadoop.hbase.io.asyncfs.AsyncFSOutput
-
The close method when error occurred.
- recoverAndClose(CancelableProgressable) - Method in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutput
-
The close method when error occurred.
- recoverAndClose(CancelableProgressable) - Method in class org.apache.hadoop.hbase.io.asyncfs.WrapperAsyncFSOutput
- RECOVERED_EDITS_DIR - Static variable in class org.apache.hadoop.hbase.HConstants
- RECOVERED_EDITS_IGNORE_EOF - Static variable in class org.apache.hadoop.hbase.regionserver.HRegion
-
Mainly used for master local region, where we will replay the WAL file directly without splitting, so it is possible to have WAL files which are not closed cleanly, in this way, hitting EOF is expected so should not consider it as a critical problem.
- RECOVERED_HFILES_DIR - Static variable in class org.apache.hadoop.hbase.HConstants
- recoverFileLease(FileSystem, Path, Configuration) - Static method in class org.apache.hadoop.hbase.util.RecoverLeaseFSUtils
- recoverFileLease(FileSystem, Path, Configuration, CancelableProgressable) - Static method in class org.apache.hadoop.hbase.util.RecoverLeaseFSUtils
-
Recover the lease from Hadoop file system, retrying multiple times.
- recoverLease(Configuration, Path) - Static method in class org.apache.hadoop.hbase.wal.AbstractFSWALProvider
- org.apache.hadoop.hbase.util.RecoverLeaseFSUtils - Class in org.apache.hadoop.hbase.util
-
Utility methods for recovering file lease for hdfs.
- recoverTask(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputCommitter
- RECOVERY_RETRY - Static variable in class org.apache.hadoop.hbase.zookeeper.ReadOnlyZKClient
- RECOVERY_RETRY_INTERVAL_MILLIS - Static variable in class org.apache.hadoop.hbase.zookeeper.ReadOnlyZKClient
- recreateScanners(List<KeyValueScanner>, boolean, boolean, boolean, ScanQueryMatcher, byte[], boolean, byte[], boolean, long, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
Recreates the scanners on the current list of active store file scanners
- RED - Enum constant in enum class org.apache.hadoop.hbase.hbtop.terminal.Color
- reduce(Stack<ByteBuffer>, Stack<Filter>, ByteBuffer) - Method in class org.apache.hadoop.hbase.filter.ParseFilter
-
This function is called while parsing the filterString and an operator is parsed
- reduce(K, Iterable<Put>, Reducer.Context) - Method in class org.apache.hadoop.hbase.mapreduce.PutCombiner
- reduce(ImmutableBytesWritable, Iterable<Cell>, Reducer.Context) - Method in class org.apache.hadoop.hbase.mapreduce.CellSortReducer
- reduce(ImmutableBytesWritable, Iterable<Put>, Reducer.Context) - Method in class org.apache.hadoop.hbase.mapreduce.PutSortReducer
- reduce(ImmutableBytesWritable, Iterable<Text>, Reducer.Context) - Method in class org.apache.hadoop.hbase.mapreduce.TextSortReducer
- reduce(ImmutableBytesWritable, Iterator<Put>, OutputCollector<ImmutableBytesWritable, Put>, Reporter) - Method in class org.apache.hadoop.hbase.mapred.IdentityTableReduce
-
No aggregation, output pairs of (key, record)
- reduce(Import.CellWritableComparable, Iterable<Cell>, Reducer.Context) - Method in class org.apache.hadoop.hbase.mapreduce.Import.CellReducer
- reduce(Text, Iterable<ImmutableBytesWritable>, Reducer.Context) - Method in class org.apache.hadoop.hbase.mob.mapreduce.MobRefReporter.MobRefReducer
- reduce(Writable, Iterable<Mutation>, Reducer.Context) - Method in class org.apache.hadoop.hbase.mapreduce.IdentityTableReducer
-
Writes each given record, consisting of the row key and the given values, to the configured
OutputFormat
. - REENTRANT_LOCK - Static variable in class org.apache.hadoop.hbase.util.ClassSize
-
Overhead for ReentrantReadWriteLock
- refCnt - Variable in class org.apache.hadoop.hbase.nio.ByteBuff
- refCnt() - Method in interface org.apache.hadoop.hbase.io.hfile.Cacheable
-
Reference count of this Cacheable.
- refCnt() - Method in class org.apache.hadoop.hbase.io.hfile.ExclusiveMemHFileBlock
- refCnt() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
- refCnt() - Method in class org.apache.hadoop.hbase.nio.ByteBuff
- org.apache.hadoop.hbase.nio.RefCnt - Class in org.apache.hadoop.hbase.nio
-
Maintain an reference count integer inside to track life cycle of
ByteBuff
, if the reference count become 0, it'll callByteBuffAllocator.Recycler.free()
exactly once. - RefCnt(ByteBuffAllocator.Recycler) - Constructor for class org.apache.hadoop.hbase.nio.RefCnt
- org.apache.hadoop.hbase.io.Reference - Class in org.apache.hadoop.hbase.io
-
A reference to the top or bottom half of a store file where 'bottom' is the first half of the file containing the keys that sort lowest and 'top' is the second half of the file with keys that sort greater than those of the bottom half.
- Reference() - Constructor for class org.apache.hadoop.hbase.io.Reference
-
Deprecated.need by pb serialization
- REFERENCE - Static variable in class org.apache.hadoop.hbase.util.ClassSize
-
Reference size is 8 bytes on 64-bit, 4 bytes on 32-bit
- ReferenceAndLinkFileFilter(FileSystem) - Constructor for class org.apache.hadoop.hbase.util.FSUtils.ReferenceAndLinkFileFilter
- referenceCache - Variable in class org.apache.hadoop.hbase.util.ObjectPool
-
Does not permit null keys.
- ReferenceFileFilter(FileSystem) - Constructor for class org.apache.hadoop.hbase.util.FSUtils.ReferenceFileFilter
- refill(long) - Method in class org.apache.hadoop.hbase.quotas.AverageIntervalRateLimiter
- refill(long) - Method in class org.apache.hadoop.hbase.quotas.FixedIntervalRateLimiter
- org.apache.hadoop.hbase.util.ReflectedFunctionCache<I,
R> - Class in org.apache.hadoop.hbase.util -
Cache to hold resolved Functions of a specific signature, generated through reflection.
- ReflectedFunctionCache(Class<R>, Class<I>, String) - Constructor for class org.apache.hadoop.hbase.util.ReflectedFunctionCache
- org.apache.hadoop.hbase.util.ReflectionUtils - Class in org.apache.hadoop.hbase.util
- ReflectionUtils() - Constructor for class org.apache.hadoop.hbase.util.ReflectionUtils
- refresh() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.batch.BatchTerminal
- refresh() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.TerminalImpl
- refresh() - Method in interface org.apache.hadoop.hbase.hbtop.terminal.Terminal
- refresh(boolean) - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenPresenter
- refresh(long, long, long, long) - Method in class org.apache.hadoop.hbase.hbtop.mode.RequestCountPerSecond
- REFRESH_CONF_KEY - Static variable in class org.apache.hadoop.hbase.quotas.QuotaCache
- refreshAndGetReplicationLoad() - Method in interface org.apache.hadoop.hbase.regionserver.ReplicationService
-
Refresh and Get ReplicationLoad
- refreshAndGetReplicationLoad() - Method in class org.apache.hadoop.hbase.replication.ReplicationSinkServiceImpl
- refreshAuthManager(Configuration, PolicyProvider) - Method in class org.apache.hadoop.hbase.ipc.RpcServer
- refreshAuthManager(Configuration, PolicyProvider) - Method in interface org.apache.hadoop.hbase.ipc.RpcServerInterface
-
Refresh authentication manager policy.
- refreshHFiles(Table) - Method in class org.apache.hadoop.hbase.client.example.RefreshHFilesClient
- refreshHFiles(TableName) - Method in class org.apache.hadoop.hbase.client.example.RefreshHFilesClient
- org.apache.hadoop.hbase.client.example.RefreshHFilesClient - Class in org.apache.hadoop.hbase.client.example
-
This client class is for invoking the refresh HFile function deployed on the Region Server side via the RefreshHFilesService.
- RefreshHFilesClient(Configuration) - Constructor for class org.apache.hadoop.hbase.client.example.RefreshHFilesClient
-
Constructor with Conf object
- refreshMetricsData() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenModel
- refreshPeerConfig(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeers
- refreshPeerNewSyncReplicationState(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeers
- refreshPeerState(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeers
- refreshStoreFiles() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
- refreshStoreFiles() - Method in class org.apache.hadoop.hbase.regionserver.HStore
- refreshStoreFiles() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Check the region's underlying store files, open the files that have not been opened yet, and remove the store file readers for store files no longer available.
- refreshStoreFiles() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Checks the underlying store files, and opens the files that have not been opened, and removes the store file readers for store files no longer available.
- refreshStoreFiles() - Method in class org.apache.hadoop.hbase.regionserver.StoreEngine
- refreshStoreFiles(boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
- refreshStoreFiles(Collection<String>) - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
Replaces the store files that the store has with the given files.
- refreshStoreFiles(Collection<String>) - Method in class org.apache.hadoop.hbase.regionserver.StoreEngine
- refreshStoreSizeAndTotalBytes() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
Update counts.
- refreshTerminal() - Method in class org.apache.hadoop.hbase.hbtop.screen.AbstractScreenView
- regex(String) - Method in class org.apache.hadoop.hbase.client.NormalizeTableFilterParams.Builder
- org.apache.hadoop.hbase.filter.RegexStringComparator - Class in org.apache.hadoop.hbase.filter
-
This comparator is for use with
CompareFilter
implementations, such asRowFilter
,QualifierFilter
, andValueFilter
, for filtering based on the value of a given column. - RegexStringComparator(String) - Constructor for class org.apache.hadoop.hbase.filter.RegexStringComparator
-
Constructor Adds Pattern.DOTALL to the underlying Pattern
- RegexStringComparator(String, int) - Constructor for class org.apache.hadoop.hbase.filter.RegexStringComparator
-
Constructor
- RegexStringComparator(String, int, RegexStringComparator.EngineType) - Constructor for class org.apache.hadoop.hbase.filter.RegexStringComparator
-
Constructor
- RegexStringComparator(String, RegexStringComparator.EngineType) - Constructor for class org.apache.hadoop.hbase.filter.RegexStringComparator
-
Constructor Adds Pattern.DOTALL to the underlying Pattern
- org.apache.hadoop.hbase.filter.RegexStringComparator.EngineType - Enum Class in org.apache.hadoop.hbase.filter
-
Engine implementation type (default=JAVA)
- regexStringNoCaseType - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
RegexStringNoCaseType byte array
- regexStringType - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
RegexStringType byte array
- region - Variable in class org.apache.hadoop.hbase.regionserver.FlushPolicy
-
The region configured for this flush policy.
- region - Variable in class org.apache.hadoop.hbase.regionserver.RegionSplitPolicy
-
The region configured for this split policy.
- region - Variable in class org.apache.hadoop.hbase.util.compaction.MajorCompactionTTLRequest
- org.apache.hadoop.hbase.regionserver.Region - Interface in org.apache.hadoop.hbase.regionserver
-
Region is a subset of HRegion with operations required for the
Coprocessors
. - REGION - Enum constant in enum class org.apache.hadoop.hbase.ClientMetaTableAccessor.QueryType
- REGION - Enum constant in enum class org.apache.hadoop.hbase.hbtop.field.Field
- REGION - Enum constant in enum class org.apache.hadoop.hbase.hbtop.mode.Mode
- REGION - Enum constant in enum class org.apache.hadoop.hbase.regionserver.wal.CompressionContext.DictionaryIndex
- REGION_COPROCESSOR_CONF_KEY - Static variable in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
- REGION_COUNT - Enum constant in enum class org.apache.hadoop.hbase.hbtop.field.Field
- REGION_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- REGION_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- REGION_CYCLE - Enum constant in enum class org.apache.hadoop.hbase.util.HbckErrorReporter.ERROR_CODE
-
Deprecated.
- REGION_EVENT - Static variable in class org.apache.hadoop.hbase.wal.WALEdit
-
Deprecated.Since 2.3.0. Remove. Not for external use. Not used.
- REGION_GROUPING_STRATEGY - Static variable in class org.apache.hadoop.hbase.wal.RegionGroupingProvider
- REGION_IMPL - Static variable in class org.apache.hadoop.hbase.HConstants
- REGION_INFO_FILE - Static variable in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
Name of the region info file that resides just under the region directory.
- REGION_MEMSTORE_REPLICATION - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
The flag to indicate whether or not the memstore should be replicated for read-replicas (CONSISTENCY => TIMELINE).
- REGION_MERGES_DIR - Static variable in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
Temporary subdirectory of the region directory used for merges.
- REGION_NAME - Enum constant in enum class org.apache.hadoop.hbase.hbtop.field.Field
- REGION_REPLICA_REPLICATION_CATALOG_CONF_KEY - Static variable in class org.apache.hadoop.hbase.util.ServerRegionReplicaUtil
-
Same as for
ServerRegionReplicaUtil.REGION_REPLICA_REPLICATION_CONF_KEY
but for catalog replication. - REGION_REPLICA_REPLICATION_CONF_KEY - Static variable in class org.apache.hadoop.hbase.util.ServerRegionReplicaUtil
-
Whether asynchronous WAL replication to the secondary region replicas is enabled or not.
- REGION_REPLICA_REPLICATION_PEER - Static variable in class org.apache.hadoop.hbase.util.ServerRegionReplicaUtil
-
Deprecated.Since 3.0.0, leave here only for implementing compatibility code.
- REGION_REPLICA_STORE_FILE_REFRESH - Static variable in class org.apache.hadoop.hbase.util.ServerRegionReplicaUtil
-
Enables or disables refreshing store files of secondary region replicas when the memory is above the global memstore lower limit.
- REGION_REPLICA_STORE_FILE_REFRESH_MEMSTORE_MULTIPLIER - Static variable in class org.apache.hadoop.hbase.util.ServerRegionReplicaUtil
-
The multiplier to use when we want to refresh a secondary region instead of flushing a primary region.
- REGION_REPLICA_WAIT_FOR_PRIMARY_FLUSH_CONF_KEY - Static variable in class org.apache.hadoop.hbase.client.RegionReplicaUtil
-
Whether or not the secondary region will wait for observing a flush / region open event from the primary region via async wal replication before enabling read requests.
- REGION_REPLICATION - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
The number of region replicas for the table.
- REGION_REPLICATION_QOS - Static variable in class org.apache.hadoop.hbase.HConstants
- REGION_SEP - Static variable in class org.apache.hadoop.hbase.mob.MobFileName
- REGION_SERVER - Enum constant in enum class org.apache.hadoop.hbase.client.ServerType
- REGION_SERVER - Enum constant in enum class org.apache.hadoop.hbase.hbtop.field.Field
- REGION_SERVER - Enum constant in enum class org.apache.hadoop.hbase.hbtop.mode.Mode
- REGION_SERVER_BULKLOAD_HANDLER_COUNT - Static variable in class org.apache.hadoop.hbase.HConstants
- REGION_SERVER_CLASS - Static variable in class org.apache.hadoop.hbase.mapreduce.TableOutputFormat
-
Deprecated.Since 2.5.9, 2.6.1 and 2.7.0, will be removed in 4.0.0. Does not take effect from long ago, see HBASE-6044.
- REGION_SERVER_HANDLER_ABORT_ON_ERROR_PERCENT - Static variable in class org.apache.hadoop.hbase.HConstants
- REGION_SERVER_HANDLER_COUNT - Static variable in class org.apache.hadoop.hbase.HConstants
- REGION_SERVER_HIGH_PRIORITY_HANDLER_COUNT - Static variable in class org.apache.hadoop.hbase.HConstants
- REGION_SERVER_IMPL - Static variable in class org.apache.hadoop.hbase.HConstants
-
Parameter name for what region server implementation to use.
- REGION_SERVER_IMPL - Static variable in class org.apache.hadoop.hbase.mapreduce.TableOutputFormat
-
Deprecated.Since 2.5.9, 2.6.1 and 2.7.0, will be removed in 4.0.0. Does not take effect from long ago, see HBASE-6044.
- REGION_SERVER_REGION_SPLIT_LIMIT - Static variable in class org.apache.hadoop.hbase.regionserver.CompactSplit
- REGION_SERVER_REPLICATION_HANDLER_COUNT - Static variable in class org.apache.hadoop.hbase.HConstants
- REGION_SERVER_RPC_SCHEDULER_FACTORY_CLASS - Static variable in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
RPC scheduler to use for the region server.
- REGION_SERVERS_SIZE_CACHE_TTL_MS - Static variable in class org.apache.hadoop.hbase.quotas.QuotaCache
- REGION_SIZE_REPORTING_CHORE_TIME_NAME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerQuotaSource
- REGION_SPLIT_THREADS_MAX - Static variable in class org.apache.hadoop.hbase.HConstants
-
The max number of threads used for splitting storefiles in parallel during the region split process.
- REGION_SPLITS_DIR - Static variable in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
Temporary subdirectory of the region directory used for splits.
- REGION_STORAGE_POLICY_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.HRegion
- org.apache.hadoop.hbase.regionserver.Region.Operation - Enum Class in org.apache.hadoop.hbase.regionserver
-
Operation enum is used in
Region.startRegionOperation()
and elsewhere to provide context for various checks. - org.apache.hadoop.hbase.regionserver.Region.RowLock - Interface in org.apache.hadoop.hbase.regionserver
-
Row lock held by a given thread.
- org.apache.hadoop.hbase.coprocessor.RegionCoprocessor - Interface in org.apache.hadoop.hbase.coprocessor
- org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment - Interface in org.apache.hadoop.hbase.coprocessor
- org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost - Class in org.apache.hadoop.hbase.regionserver
-
Implements the coprocessor environment and runtime support for coprocessors loaded within a
Region
. - RegionCoprocessorHost(HRegion, RegionServerServices, Configuration) - Constructor for class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
Constructor
- org.apache.hadoop.hbase.client.RegionCoprocessorServiceExec - Class in org.apache.hadoop.hbase.client
-
Represents a coprocessor service method execution against a single region.
- RegionCoprocessorServiceExec(byte[], byte[], Descriptors.MethodDescriptor, Message) - Constructor for class org.apache.hadoop.hbase.client.RegionCoprocessorServiceExec
- RegionDirFilter(FileSystem) - Constructor for class org.apache.hadoop.hbase.util.FSUtils.RegionDirFilter
- regionDirPattern - Static variable in class org.apache.hadoop.hbase.util.FSUtils.RegionDirFilter
- org.apache.hadoop.hbase.RegionException - Exception in org.apache.hadoop.hbase
-
Thrown when something happens related to region handling.
- RegionException() - Constructor for exception org.apache.hadoop.hbase.RegionException
-
default constructor
- RegionException(String) - Constructor for exception org.apache.hadoop.hbase.RegionException
-
Constructor
- org.apache.hadoop.hbase.wal.RegionGroupingProvider - Class in org.apache.hadoop.hbase.wal
-
A WAL Provider that returns a WAL per group of regions.
- RegionGroupingProvider() - Constructor for class org.apache.hadoop.hbase.wal.RegionGroupingProvider
- org.apache.hadoop.hbase.wal.RegionGroupingProvider.RegionGroupingStrategy - Interface in org.apache.hadoop.hbase.wal
-
Map identifiers to a group number.
- org.apache.hadoop.hbase.client.RegionInfo - Interface in org.apache.hadoop.hbase.client
-
Information about a region.
- REGIONINFO_QUALIFIER - Static variable in class org.apache.hadoop.hbase.HConstants
-
The regioninfo column qualifier
- REGIONINFO_QUALIFIER_STR - Static variable in class org.apache.hadoop.hbase.HConstants
-
The RegionInfo qualifier as a string
- org.apache.hadoop.hbase.client.RegionInfoBuilder - Class in org.apache.hadoop.hbase.client
- org.apache.hadoop.hbase.client.RegionInfoDisplay - Class in org.apache.hadoop.hbase.client
-
Utility used composing RegionInfo for 'display'; e.g.
- RegionInfoDisplay() - Constructor for class org.apache.hadoop.hbase.client.RegionInfoDisplay
- org.apache.hadoop.hbase.client.RegionLoadStats - Class in org.apache.hadoop.hbase.client
-
POJO representing region server load
- RegionLoadStats(int, int, int) - Constructor for class org.apache.hadoop.hbase.client.RegionLoadStats
- org.apache.hadoop.hbase.RegionLocations - Class in org.apache.hadoop.hbase
-
Container for holding a list of
HRegionLocation
's that correspond to the same range. - RegionLocations(Collection<HRegionLocation>) - Constructor for class org.apache.hadoop.hbase.RegionLocations
- RegionLocations(HRegionLocation...) - Constructor for class org.apache.hadoop.hbase.RegionLocations
-
Constructs the region location list.
- org.apache.hadoop.hbase.client.RegionLocator - Interface in org.apache.hadoop.hbase.client
-
Used to view region location information for a single HBase table.
- regionLock(List<RegionInfo>, String, Abortable) - Method in class org.apache.hadoop.hbase.client.locking.LockServiceClient
-
Create a new EntityLock object to acquire exclusive lock on multiple regions of same tables.
- regionLock(List<RegionInfo>, String, Abortable) - Method in class org.apache.hadoop.hbase.MockRegionServerServices
- regionLock(List<RegionInfo>, String, Abortable) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
- regionLock(List<RegionInfo>, String, Abortable) - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
Master based locks on namespaces/tables/regions.
- regionMaxSeqIdInStores - Variable in class org.apache.hadoop.hbase.wal.WALSplitter
- org.apache.hadoop.hbase.RegionMetrics - Interface in org.apache.hadoop.hbase
-
Encapsulates per-region load metrics.
- org.apache.hadoop.hbase.RegionMetricsBuilder - Class in org.apache.hadoop.hbase
- org.apache.hadoop.hbase.hbtop.mode.RegionModeStrategy - Class in org.apache.hadoop.hbase.hbtop.mode
-
Implementation for
ModeStrategy
for Region Mode. - org.apache.hadoop.hbase.exceptions.RegionMovedException - Exception in org.apache.hadoop.hbase.exceptions
-
Subclass if the server knows the region is now on another server.
- RegionMovedException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.RegionMovedException
-
For hadoop.ipc internal call.
- RegionMovedException(ServerName, long) - Constructor for exception org.apache.hadoop.hbase.exceptions.RegionMovedException
- org.apache.hadoop.hbase.util.RegionMover - Class in org.apache.hadoop.hbase.util
-
Tool for loading/unloading regions to/from given regionserver This tool can be run from Command line directly as a utility.
- org.apache.hadoop.hbase.util.RegionMover.RegionMoverBuilder - Class in org.apache.hadoop.hbase.util
-
Builder for Region mover.
- RegionMoverBuilder(String) - Constructor for class org.apache.hadoop.hbase.util.RegionMover.RegionMoverBuilder
- RegionMoverBuilder(String, Configuration) - Constructor for class org.apache.hadoop.hbase.util.RegionMover.RegionMoverBuilder
- regionNormalizerZNode - 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.
- org.apache.hadoop.hbase.coprocessor.RegionObserver - Interface in org.apache.hadoop.hbase.coprocessor
-
Coprocessors implement this interface to observe and mediate client actions on the region.
- org.apache.hadoop.hbase.coprocessor.RegionObserver.MutationType - Enum Class in org.apache.hadoop.hbase.coprocessor
-
Mutation type for postMutationBeforeWAL hook
- regionOffline(RegionInfo) - Method in interface org.apache.hadoop.hbase.master.LoadBalancer
-
Marks the region as offline at balancer.
- regionOffline(RegionInfo) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupBasedLoadBalancer
- org.apache.hadoop.hbase.client.RegionOfflineException - Exception in org.apache.hadoop.hbase.client
-
Thrown when a table can not be located
- RegionOfflineException() - Constructor for exception org.apache.hadoop.hbase.client.RegionOfflineException
-
default constructor
- RegionOfflineException(String) - Constructor for exception org.apache.hadoop.hbase.client.RegionOfflineException
- regionOnline(RegionInfo, ServerName) - Method in interface org.apache.hadoop.hbase.master.LoadBalancer
-
Marks the region as online at balancer.
- regionOnline(RegionInfo, ServerName) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupBasedLoadBalancer
- org.apache.hadoop.hbase.exceptions.RegionOpeningException - Exception in org.apache.hadoop.hbase.exceptions
-
Subclass if the server knows the region is now on another server.
- RegionOpeningException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.RegionOpeningException
- org.apache.hadoop.hbase.master.RegionPlacementMaintainer - Class in org.apache.hadoop.hbase.master
-
A tool that is used for manipulating and viewing favored nodes information for regions.
- RegionPlacementMaintainer(Configuration) - Constructor for class org.apache.hadoop.hbase.master.RegionPlacementMaintainer
- RegionPlacementMaintainer(Configuration, boolean, boolean) - Constructor for class org.apache.hadoop.hbase.master.RegionPlacementMaintainer
- org.apache.hadoop.hbase.master.RegionPlacementMaintainer.RandomizedMatrix - Class in org.apache.hadoop.hbase.master
-
Some algorithms for solving the assignment problem may traverse workers or jobs in linear order which may result in skewing the assignments of the first jobs in the matrix toward the last workers in the matrix if the costs are uniform.
- org.apache.hadoop.hbase.master.RegionPlan - Class in org.apache.hadoop.hbase.master
-
Stores the plan for the move of an individual region.
- RegionPlan(RegionInfo, ServerName, ServerName) - Constructor for class org.apache.hadoop.hbase.master.RegionPlan
-
Instantiate a plan for a region move, moving the specified region from the specified source server to the specified destination server.
- org.apache.hadoop.hbase.master.RegionPlan.RegionPlanComparator - Class in org.apache.hadoop.hbase.master
- RegionPlanComparator() - Constructor for class org.apache.hadoop.hbase.master.RegionPlan.RegionPlanComparator
- org.apache.hadoop.hbase.regionserver.regionreplication.RegionReplicationBufferManager - Class in org.apache.hadoop.hbase.regionserver.regionreplication
-
Manager the buffer size for all
RegionReplicationSink
. - RegionReplicationBufferManager(RegionServerServices) - Constructor for class org.apache.hadoop.hbase.regionserver.regionreplication.RegionReplicationBufferManager
- regionReplicationSink - Variable in class org.apache.hadoop.hbase.regionserver.HRegion
- org.apache.hadoop.hbase.regionserver.regionreplication.RegionReplicationSink - Class in org.apache.hadoop.hbase.regionserver.regionreplication
-
The class for replicating WAL edits to secondary replicas, one instance per region.
- RegionReplicationSink(Configuration, RegionInfo, TableDescriptor, RegionReplicationBufferManager, Runnable, AsyncClusterConnection) - Constructor for class org.apache.hadoop.hbase.regionserver.regionreplication.RegionReplicationSink
- org.apache.hadoop.hbase.client.RegionReplicaUtil - Class in org.apache.hadoop.hbase.client
-
Utility methods which contain the logic for regions and replicas.
- RegionReplicaUtil() - Constructor for class org.apache.hadoop.hbase.client.RegionReplicaUtil
- REGIONS_IN_TRANSITION - Enum constant in enum class org.apache.hadoop.hbase.ClusterMetrics.Option
-
metrics about regions in transition
- REGIONS_PER_SERVER_KEY - Static variable in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- REGIONS_RECOVERY_INTERVAL - Static variable in class org.apache.hadoop.hbase.HConstants
- org.apache.hadoop.hbase.regionserver.RegionScanner - Interface in org.apache.hadoop.hbase.regionserver
-
RegionScanner describes iterators over rows in an HRegion.
- REGIONSERVER - Enum constant in enum class org.apache.hadoop.hbase.util.DNS.ServerType
- REGIONSERVER - Static variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
region server process name
- REGIONSERVER_ADMIN_SERVICE_CONFIG - Static variable in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
Services launched in RSRpcServices.
- REGIONSERVER_BOOTSTRAP_NODES_SERVICE_CONFIG - Static variable in class org.apache.hadoop.hbase.regionserver.RSRpcServices
- REGIONSERVER_CLIENT_META_SERVICE_CONFIG - Static variable in class org.apache.hadoop.hbase.regionserver.RSRpcServices
- REGIONSERVER_CLIENT_SERVICE_CONFIG - Static variable in class org.apache.hadoop.hbase.regionserver.RSRpcServices
- REGIONSERVER_COPROCESSOR_CONF_KEY - Static variable in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
- REGIONSERVER_INFO_PORT - Static variable in class org.apache.hadoop.hbase.HConstants
-
A configuration key for regionserver info port
- REGIONSERVER_INFO_PORT_AUTO - Static variable in class org.apache.hadoop.hbase.HConstants
-
A flag that enables automatic selection of regionserver info port
- REGIONSERVER_KRB_KEYTAB_FILE - Static variable in class org.apache.hadoop.hbase.security.SecurityConstants
- REGIONSERVER_KRB_PRINCIPAL - Static variable in class org.apache.hadoop.hbase.security.SecurityConstants
- REGIONSERVER_META_STOREFILE_REFRESH_PERIOD - Static variable in class org.apache.hadoop.hbase.regionserver.StorefileRefresherChore
-
Whether all storefiles should be refreshed, as opposed to just hbase:meta's Meta region doesn't have WAL replication for replicas enabled yet
- REGIONSERVER_METRICS_PERIOD - Static variable in class org.apache.hadoop.hbase.HConstants
-
The period (in milliseconds) between computing region server point in time metrics
- REGIONSERVER_PORT - Static variable in class org.apache.hadoop.hbase.HConstants
-
Parameter name for port region server listens on.
- REGIONSERVER_STOREFILE_REFRESH_PERIOD - Static variable in class org.apache.hadoop.hbase.regionserver.StorefileRefresherChore
-
The period (in milliseconds) for refreshing the store files for the secondary regions.
- org.apache.hadoop.hbase.regionserver.RegionServerAbortedException - Exception in org.apache.hadoop.hbase.regionserver
-
Thrown by the region server when it is aborting.
- RegionServerAbortedException(String) - Constructor for exception org.apache.hadoop.hbase.regionserver.RegionServerAbortedException
- org.apache.hadoop.hbase.regionserver.RegionServerAccounting - Class in org.apache.hadoop.hbase.regionserver
-
RegionServerAccounting keeps record of some basic real time information about the Region Server.
- RegionServerAccounting(Configuration) - Constructor for class org.apache.hadoop.hbase.regionserver.RegionServerAccounting
- org.apache.hadoop.hbase.coprocessor.RegionServerCoprocessor - Interface in org.apache.hadoop.hbase.coprocessor
- org.apache.hadoop.hbase.coprocessor.RegionServerCoprocessorEnvironment - Interface in org.apache.hadoop.hbase.coprocessor
- org.apache.hadoop.hbase.regionserver.RegionServerCoprocessorHost - Class in org.apache.hadoop.hbase.regionserver
- RegionServerCoprocessorHost(RegionServerServices, Configuration) - Constructor for class org.apache.hadoop.hbase.regionserver.RegionServerCoprocessorHost
- org.apache.hadoop.hbase.client.RegionServerCoprocessorRpcChannelImpl - Class in org.apache.hadoop.hbase.client
-
The implementation of a region server based coprocessor rpc channel.
- org.apache.hadoop.hbase.master.RegionServerList - Interface in org.apache.hadoop.hbase.master
-
For storing the region server list.
- org.apache.hadoop.hbase.hbtop.mode.RegionServerModeStrategy - Class in org.apache.hadoop.hbase.hbtop.mode
-
Implementation for
ModeStrategy
for RegionServer Mode. - org.apache.hadoop.hbase.coprocessor.RegionServerObserver - Interface in org.apache.hadoop.hbase.coprocessor
-
Defines coprocessor hooks for interacting with operations on the
HRegionServer
process. - regionServerRemoved(ServerName) - Method in interface org.apache.hadoop.hbase.replication.ReplicationListener
-
A region server has been removed from the local cluster
- regionServerReport(ServerName, ServerMetrics) - Method in class org.apache.hadoop.hbase.master.ServerManager
- regionServerReport(RpcController, RegionServerStatusProtos.RegionServerReportRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- regionServerReport(RpcController, RegionServerStatusProtos.RegionServerReportRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServicesVersionWrapper
- org.apache.hadoop.hbase.quotas.RegionServerRpcQuotaManager - Class in org.apache.hadoop.hbase.quotas
-
Region Server Quota Manager.
- RegionServerRpcQuotaManager(RegionServerServices) - Constructor for class org.apache.hadoop.hbase.quotas.RegionServerRpcQuotaManager
- org.apache.hadoop.hbase.regionserver.RegionServerRunningException - Exception in org.apache.hadoop.hbase.regionserver
-
Thrown if the region server log directory exists (which indicates another region server is running at the same address)
- RegionServerRunningException() - Constructor for exception org.apache.hadoop.hbase.regionserver.RegionServerRunningException
-
Default Constructor
- RegionServerRunningException(String) - Constructor for exception org.apache.hadoop.hbase.regionserver.RegionServerRunningException
-
Constructs the exception and supplies a string as the message
- org.apache.hadoop.hbase.regionserver.RegionServerServices - Interface in org.apache.hadoop.hbase.regionserver
-
A curated subset of services provided by
HRegionServer
. - org.apache.hadoop.hbase.regionserver.RegionServerServices.PostOpenDeployContext - Class in org.apache.hadoop.hbase.regionserver
-
Context for postOpenDeployTasks().
- org.apache.hadoop.hbase.regionserver.RegionServerServices.RegionStateTransitionContext - Class in org.apache.hadoop.hbase.regionserver
- org.apache.hadoop.hbase.quotas.RegionServerSpaceQuotaManager - Class in org.apache.hadoop.hbase.quotas
-
A manager for filesystem space quotas in the RegionServer.
- RegionServerSpaceQuotaManager(RegionServerServices) - Constructor for class org.apache.hadoop.hbase.quotas.RegionServerSpaceQuotaManager
- regionServerStartup(RpcController, RegionServerStatusProtos.RegionServerStartupRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- regionServerStartup(RpcController, RegionServerStatusProtos.RegionServerStartupRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServicesVersionWrapper
- org.apache.hadoop.hbase.regionserver.RegionServerStoppedException - Exception in org.apache.hadoop.hbase.regionserver
-
Thrown by the region server when it is in shutting down state.
- RegionServerStoppedException(String) - Constructor for exception org.apache.hadoop.hbase.regionserver.RegionServerStoppedException
- RegionServerThread(HRegionServer, int) - Constructor for class org.apache.hadoop.hbase.util.JVMClusterUtil.RegionServerThread
- org.apache.hadoop.hbase.master.RegionServerTracker - Class in org.apache.hadoop.hbase.master
-
Tracks the online region servers via ZK.
- RegionServerTracker(ZKWatcher, MasterServices) - Constructor for class org.apache.hadoop.hbase.master.RegionServerTracker
- regionServices - Variable in class org.apache.hadoop.hbase.regionserver.AbstractMemStore
- org.apache.hadoop.hbase.regionserver.RegionServicesForStores - Class in org.apache.hadoop.hbase.regionserver
-
Services a Store needs from a Region.
- RegionServicesForStores(HRegion, RegionServerServices) - Constructor for class org.apache.hadoop.hbase.regionserver.RegionServicesForStores
- regionsInQueue - Variable in class org.apache.hadoop.hbase.regionserver.MemStoreFlusher
- org.apache.hadoop.hbase.quotas.RegionSize - Interface in org.apache.hadoop.hbase.quotas
-
Interface that encapsulates optionally sending a Region's size to the master.
- org.apache.hadoop.hbase.mapreduce.RegionSizeCalculator - Class in org.apache.hadoop.hbase.mapreduce
-
Computes size of each region for given table and given column families.
- RegionSizeCalculator(RegionLocator, Admin) - Constructor for class org.apache.hadoop.hbase.mapreduce.RegionSizeCalculator
-
Computes size of each region for table and given column families.
- org.apache.hadoop.hbase.quotas.RegionSizeImpl - Class in org.apache.hadoop.hbase.quotas
-
An object encapsulating a Region's size and whether it's been reported to the master since the value last changed.
- RegionSizeImpl(long) - Constructor for class org.apache.hadoop.hbase.quotas.RegionSizeImpl
- org.apache.hadoop.hbase.quotas.RegionSizeReportingChore - Class in org.apache.hadoop.hbase.quotas
-
A Chore which sends the region size reports on this RegionServer to the Master.
- RegionSizeReportingChore(RegionServerServices) - Constructor for class org.apache.hadoop.hbase.quotas.RegionSizeReportingChore
- org.apache.hadoop.hbase.quotas.RegionSizeStore - Interface in org.apache.hadoop.hbase.quotas
-
An interface for concurrently storing and updating the size of a Region.
- org.apache.hadoop.hbase.quotas.RegionSizeStoreFactory - Class in org.apache.hadoop.hbase.quotas
-
A factory class for creating implementations of
RegionSizeStore
. - org.apache.hadoop.hbase.quotas.RegionSizeStoreImpl - Class in org.apache.hadoop.hbase.quotas
-
A
RegionSizeStore
implementation backed by a ConcurrentHashMap. - RegionSizeStoreImpl() - Constructor for class org.apache.hadoop.hbase.quotas.RegionSizeStoreImpl
- org.apache.hadoop.hbase.util.RegionSplitCalculator<R extends org.apache.hadoop.hbase.util.KeyRange> - Class in org.apache.hadoop.hbase.util
-
This is a generic region split calculator.
- RegionSplitCalculator(Comparator<R>) - Constructor for class org.apache.hadoop.hbase.util.RegionSplitCalculator
- org.apache.hadoop.hbase.regionserver.RegionSplitPolicy - Class in org.apache.hadoop.hbase.regionserver
-
A split policy determines when a Region should be split.
- RegionSplitPolicy() - Constructor for class org.apache.hadoop.hbase.regionserver.RegionSplitPolicy
- org.apache.hadoop.hbase.regionserver.RegionSplitRestriction - Class in org.apache.hadoop.hbase.regionserver
-
A split restriction that restricts the pattern of the split point.
- RegionSplitRestriction() - Constructor for class org.apache.hadoop.hbase.regionserver.RegionSplitRestriction
- org.apache.hadoop.hbase.util.RegionSplitter - Class in org.apache.hadoop.hbase.util
-
The
RegionSplitter
class provides several utilities to help in the administration lifecycle for developers who choose to manually split regions instead of having HBase handle that automatically. - RegionSplitter() - Constructor for class org.apache.hadoop.hbase.util.RegionSplitter
- org.apache.hadoop.hbase.util.RegionSplitter.DecimalStringSplit - Class in org.apache.hadoop.hbase.util
-
The format of a DecimalStringSplit region boundary is the ASCII representation of reversed sequential number, or any other uniformly distributed decimal value.
- org.apache.hadoop.hbase.util.RegionSplitter.HexStringSplit - Class in org.apache.hadoop.hbase.util
-
HexStringSplit is a well-known
RegionSplitter.SplitAlgorithm
for choosing region boundaries. - org.apache.hadoop.hbase.util.RegionSplitter.NumberStringSplit - Class in org.apache.hadoop.hbase.util
- org.apache.hadoop.hbase.util.RegionSplitter.SplitAlgorithm - Interface in org.apache.hadoop.hbase.util
-
A generic interface for the RegionSplitter code to use for all it's functionality.
- org.apache.hadoop.hbase.util.RegionSplitter.UniformSplit - Class in org.apache.hadoop.hbase.util
-
A SplitAlgorithm that divides the space of possible keys evenly.
- org.apache.hadoop.hbase.master.RegionsRecoveryChore - Class in org.apache.hadoop.hbase.master
-
This chore, every time it runs, will try to recover regions with high store ref count by reopening them
- org.apache.hadoop.hbase.master.RegionsRecoveryConfigManager - Class in org.apache.hadoop.hbase.master
-
Config manager for RegionsRecovery Chore - Dynamically reload config and update chore accordingly
- org.apache.hadoop.hbase.rest.RegionsResource - Class in org.apache.hadoop.hbase.rest
- RegionsResource(TableResource) - Constructor for class org.apache.hadoop.hbase.rest.RegionsResource
-
Constructor
- org.apache.hadoop.hbase.master.RegionState - Class in org.apache.hadoop.hbase.master
-
State of a Region while undergoing transitions.
- RegionState(RegionInfo, RegionState.State, long, ServerName) - Constructor for class org.apache.hadoop.hbase.master.RegionState
- RegionState(RegionInfo, RegionState.State, long, ServerName, long) - Constructor for class org.apache.hadoop.hbase.master.RegionState
- RegionState(RegionInfo, RegionState.State, ServerName) - Constructor for class org.apache.hadoop.hbase.master.RegionState
- org.apache.hadoop.hbase.master.RegionState.State - Enum Class in org.apache.hadoop.hbase.master
- org.apache.hadoop.hbase.RegionStateListener - Interface in org.apache.hadoop.hbase
-
The listener interface for receiving region state events.
- org.apache.hadoop.hbase.client.RegionStatesCount - Class in org.apache.hadoop.hbase.client
- org.apache.hadoop.hbase.client.RegionStatesCount.RegionStatesCountBuilder - Class in org.apache.hadoop.hbase.client
- RegionStatesCountBuilder() - Constructor for class org.apache.hadoop.hbase.client.RegionStatesCount.RegionStatesCountBuilder
- RegionStateTransitionContext(RegionServerStatusProtos.RegionStateTransition.TransitionCode, long, long, long, RegionInfo...) - Constructor for class org.apache.hadoop.hbase.regionserver.RegionServerServices.RegionStateTransitionContext
- RegionStateTransitionContext(RegionServerStatusProtos.RegionStateTransition.TransitionCode, long, long, long, RegionInfo, long) - Constructor for class org.apache.hadoop.hbase.regionserver.RegionServerServices.RegionStateTransitionContext
- RegionStatistics() - Constructor for class org.apache.hadoop.hbase.client.backoff.ServerStatistics.RegionStatistics
- RegionStats(MetricRegistry, String) - Constructor for class org.apache.hadoop.hbase.client.MetricsConnection.RegionStats
- org.apache.hadoop.hbase.RegionTooBusyException - Exception in org.apache.hadoop.hbase
-
Thrown by a region server if it will block and wait to serve a request.
- RegionTooBusyException(String) - Constructor for exception org.apache.hadoop.hbase.RegionTooBusyException
- register() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsUserSource
- register() - Method in class org.apache.hadoop.hbase.regionserver.MetricsUserSourceImpl
- register(String, String, Object) - Method in interface org.apache.hadoop.hbase.metrics.MBeanSource
-
Register an mbean with the underlying metrics system
- register(String, String, Object) - Method in class org.apache.hadoop.hbase.metrics.MBeanSourceImpl
-
Register an mbean with the underlying metrics system
- register(String, Gauge<T>) - Method in interface org.apache.hadoop.hbase.metrics.MetricRegistry
-
Register a
Gauge
. - register(String, Metric) - Method in interface org.apache.hadoop.hbase.metrics.MetricRegistry
-
Registers the
Metric
with the given name if there does not exist one with the same name. - register(MetricsRegionSource) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionAggregateSource
-
Register a MetricsRegionSource as being open.
- register(MetricsRegionSource) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionAggregateSourceImpl
- register(MetricsUserSource) - Method in class org.apache.hadoop.hbase.regionserver.MetricsUserAggregateSourceImpl
- registerAll(MetricSet) - Method in interface org.apache.hadoop.hbase.metrics.MetricRegistry
-
Registers the
Metric
s in the given MetricSet. - registerChildren(ConfigurationManager) - Method in interface org.apache.hadoop.hbase.conf.PropagatingConfigurationObserver
-
Needs to be called to register the children to the manager.
- registerChildren(ConfigurationManager) - Method in class org.apache.hadoop.hbase.regionserver.CompactSplit
-
Needs to be called to register the children to the manager.
- registerChildren(ConfigurationManager) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Needs to be called to register the children to the manager.
- registerChildren(ConfigurationManager) - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
Needs to be called to register the children to the manager.
- registerChildren(ConfigurationManager) - Method in class org.apache.hadoop.hbase.regionserver.PrefetchExecutorNotifier
-
Needs to be called to register the children to the manager.
- registerDeserializer(CacheableDeserializer<Cacheable>) - Static method in class org.apache.hadoop.hbase.io.hfile.CacheableDeserializerIdManager
-
Register the given
Cacheable
-- usually an hfileblock instance, these implement the Cacheable Interface -- deserializer and generate a unique identifier id for it and return this as our result. - registerFilter(String, String) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Register a new filter with the parser.
- registerFilters(Configuration) - Static method in class org.apache.hadoop.hbase.thrift.ThriftServer
- registerFlushRequestListener(FlushRequestListener) - Method in interface org.apache.hadoop.hbase.regionserver.FlushRequester
-
Register a FlushRequestListener
- registerFlushRequestListener(FlushRequestListener) - Method in class org.apache.hadoop.hbase.regionserver.MemStoreFlusher
-
Register a MemstoreFlushListener
- registerListener() - Method in interface org.apache.hadoop.hbase.coordination.SplitLogWorkerCoordination
-
Deprecated.set the listener for task changes.
- registerListener() - Method in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination
- registerListener(ServerListener) - Method in class org.apache.hadoop.hbase.master.ServerManager
-
Add the listener to the notification list.
- registerListener(ZKListener) - Method in class org.apache.hadoop.hbase.zookeeper.ZKWatcher
-
Register the specified listener to receive ZooKeeper events.
- registerListenerFirst(ZKListener) - Method in class org.apache.hadoop.hbase.zookeeper.ZKWatcher
-
Register the specified listener to receive ZooKeeper events and add it as the first in the list of current listeners.
- registerMetrics() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableSource
- registerMetrics() - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableSourceImpl
- registerObserver(ConfigurationObserver) - Method in class org.apache.hadoop.hbase.conf.ConfigurationManager
-
Register an observer class
- registerPeerConfigListener(ReplicationPeerConfigListener) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeer
-
Register a peer config listener to catch the peer config change event.
- registerPeerConfigListener(ReplicationPeerConfigListener) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerImpl
- registerService(Service) - Method in class org.apache.hadoop.hbase.master.HMaster
- registerService(Service) - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Registers a new protocol buffer
Service
subclass as a master coprocessor endpoint. - registerService(Service) - Method in class org.apache.hadoop.hbase.MockRegionServerServices
- registerService(Service) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Registers a new protocol buffer
Service
subclass as a coprocessor endpoint to be available for handlingHRegion.execService(RpcController, CoprocessorServiceCall)
calls. - registerService(Service) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
- registerService(Service) - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
Registers a new protocol buffer
Service
subclass as a coprocessor endpoint to be available for handling - registerTuneObserver(HeapMemoryManager.HeapMemoryTuneObserver) - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager
- registerWALActionsListener(WALActionsListener) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
- registerWALActionsListener(WALActionsListener) - Method in interface org.apache.hadoop.hbase.wal.WAL
-
Registers WALActionsListener
- registry - Variable in class org.apache.hadoop.hbase.metrics.BaseSourceImpl
-
Note that there are at least 4 MetricRegistry definitions in the source code.
- REGISTRY_PREAMBLE_HEADER - Static variable in interface org.apache.hadoop.hbase.ipc.RpcClient
- reinit(Configuration) - Method in interface org.apache.hadoop.hbase.io.compress.CanReinit
- REJECT_DECOMMISSIONED_HOSTS_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
-
Default value of
HConstants.REJECT_DECOMMISSIONED_HOSTS_KEY
- REJECT_DECOMMISSIONED_HOSTS_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
Should the HMaster reject hosts of decommissioned RegionServers, bypass matching their port and startcode parts of their ServerName or not? When True, the HMaster will reject a RegionServer's request to `reportForDuty` if it's hostname exists in the list of decommissioned RegionServers it maintains internally.
- release() - Method in interface org.apache.hadoop.hbase.io.hfile.Cacheable
-
Decrease its reference count, and if no reference then free the memory of this object, its backend is usually a
ByteBuff
, and we will put its NIO ByteBuffers back toByteBuffAllocator
- release() - Method in class org.apache.hadoop.hbase.io.hfile.ExclusiveMemHFileBlock
- release() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
Call
ByteBuff.release()
to decrease the reference count, if no other reference, it will return back theByteBuffer
toByteBuffAllocator
- release() - Method in class org.apache.hadoop.hbase.nio.ByteBuff
- release() - Method in class org.apache.hadoop.hbase.nio.RefCnt
- release() - Method in class org.apache.hadoop.hbase.regionserver.HRegion.RowLockImpl
- release() - Method in interface org.apache.hadoop.hbase.regionserver.Region.RowLock
-
Release the given lock.
- release(int) - Method in interface org.apache.hadoop.hbase.nio.HBaseReferenceCounted
- release(int) - Method in class org.apache.hadoop.hbase.nio.RefCnt
- release(ServerName) - Method in class org.apache.hadoop.hbase.master.WorkerAssigner
- releaseByWAL() - Method in class org.apache.hadoop.hbase.ipc.ServerCall
- releaseIfNotCurBlock(HFileBlock) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
-
The curBlock will be released by shipping or close method, so only need to consider releasing the block, which was read from HFile before and not referenced by curBlock.
- releaseLockEntry(IdLock.Entry) - Method in class org.apache.hadoop.hbase.util.IdLock
-
Must be called in a finally block to decrease the internal counter and remove the monitor object for the given id if the caller is the last client.
- releaseResources() - Method in class org.apache.hadoop.hbase.io.ByteBufferListOutputStream
-
Release the resources it uses (The ByteBuffers) which are obtained from pool.
- releaseSplitWALWorker(ServerName, MasterProcedureScheduler) - Method in class org.apache.hadoop.hbase.master.SplitWALManager
-
After the worker finished the split WAL task, it will release the worker, and wake up all the suspend procedures in the ProcedureEvent
- reload(Configuration) - Method in enum class org.apache.hadoop.hbase.io.compress.Compression.Algorithm
-
Reload configuration for the given algorithm.
- reloadConfiguration() - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
- RELOGIN_IS_IN_PROGRESS - Static variable in class org.apache.hadoop.hbase.ipc.RpcConnectionConstants
- remaining() - Method in class org.apache.hadoop.hbase.nio.ByteBuff
-
Returns the number of elements between the current position and the limit.
- remaining() - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
Returns the number of elements between the current position and the limit.
- remaining() - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
- remainingCapacity() - Method in class org.apache.hadoop.hbase.ipc.AdaptiveLifoCoDelCallQueue
- remainingCapacity() - Method in class org.apache.hadoop.hbase.thrift.CallQueue
- remainingCapacity() - Method in class org.apache.hadoop.hbase.util.BoundedPriorityBlockingQueue
- remainingTasksInCoordination() - Method in interface org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination
-
Deprecated.Return the number of remaining tasks
- remainingTasksInCoordination() - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
- remainingTimeNs() - Method in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCaller
- remainingTimeNs(long) - Method in class org.apache.hadoop.hbase.client.backoff.HBaseServerExceptionPauseManager
- REMOTE_CLUSTER_CONF_PREFIX - Static variable in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
- REMOTE_CLUSTER_ZOOKEEPER_CLIENT_PORT_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
- REMOTE_CLUSTER_ZOOKEEPER_QUORUM_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
- REMOTE_CLUSTER_ZOOKEEPER_ZNODE_PARENT_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
- REMOTE_WAL_DIR_NAME - Static variable in class org.apache.hadoop.hbase.replication.ReplicationUtils
- REMOTE_WAL_REPLAY_SUFFIX - Static variable in class org.apache.hadoop.hbase.replication.ReplicationUtils
- REMOTE_WAL_SNAPSHOT_SUFFIX - Static variable in class org.apache.hadoop.hbase.replication.ReplicationUtils
- remoteAddress - Variable in class org.apache.hadoop.hbase.ipc.ServerCall
- remoteProcedureComplete(long, long, Throwable) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
- remoteProcedureCompleted(long) - Method in class org.apache.hadoop.hbase.master.HMaster
- remoteProcedureFailed(long, RemoteProcedureException) - Method in class org.apache.hadoop.hbase.master.HMaster
- org.apache.hadoop.hbase.ipc.RemoteWithExtrasException - Exception in org.apache.hadoop.hbase.ipc
-
A
RemoteException
with some extra information. - RemoteWithExtrasException(String, String, boolean) - Constructor for exception org.apache.hadoop.hbase.ipc.RemoteWithExtrasException
- RemoteWithExtrasException(String, String, boolean, boolean) - Constructor for exception org.apache.hadoop.hbase.ipc.RemoteWithExtrasException
- RemoteWithExtrasException(String, String, String, int, boolean) - Constructor for exception org.apache.hadoop.hbase.ipc.RemoteWithExtrasException
- RemoteWithExtrasException(String, String, String, int, boolean, boolean) - Constructor for exception org.apache.hadoop.hbase.ipc.RemoteWithExtrasException
- remove() - Method in class org.apache.hadoop.hbase.ipc.AdaptiveLifoCoDelCallQueue
- remove() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreCompactorSegmentsIterator
- remove() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreMergerSegmentsIterator
- remove() - Method in class org.apache.hadoop.hbase.rest.RowResultGenerator
- remove() - Method in class org.apache.hadoop.hbase.rest.ScannerResultGenerator
- remove() - Method in class org.apache.hadoop.hbase.thrift.CallQueue
- remove() - Method in class org.apache.hadoop.hbase.types.StructIterator
- remove() - Method in class org.apache.hadoop.hbase.util.AvlUtil.AvlTreeIterator
- remove() - Method in class org.apache.hadoop.hbase.util.ConcatenatedLists.Iterator
- remove(int) - Method in class org.apache.hadoop.hbase.RegionLocations
-
Removes location of the given replicaId from the list
- remove(int) - Method in class org.apache.hadoop.hbase.util.SortedList
- remove(Object) - Method in class org.apache.hadoop.hbase.hbtop.Record
- remove(Object) - Method in class org.apache.hadoop.hbase.io.hfile.HFileInfo
- remove(Object) - Method in class org.apache.hadoop.hbase.ipc.AdaptiveLifoCoDelCallQueue
- remove(Object) - Method in class org.apache.hadoop.hbase.regionserver.CellFlatMap
- remove(Object) - Method in class org.apache.hadoop.hbase.regionserver.CellSet
- remove(Object) - Method in class org.apache.hadoop.hbase.thrift.CallQueue
- remove(Object) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
- remove(Object) - Method in class org.apache.hadoop.hbase.util.BoundedPriorityBlockingQueue
- remove(Object) - Method in class org.apache.hadoop.hbase.util.SortedList
- remove(Object, Object) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
- remove(String) - Method in interface org.apache.hadoop.hbase.metrics.MetricRegistry
-
Removes the metric with the given name.
- remove(String) - Method in class org.apache.hadoop.hbase.rest.client.Cluster
-
Remove a node from the cluster
- remove(String, int) - Method in class org.apache.hadoop.hbase.rest.client.Cluster
-
Remove a node from the cluster
- remove(String, Metric) - Method in interface org.apache.hadoop.hbase.metrics.MetricRegistry
-
Removes the metric with the given name only if it is registered to the provided metric.
- remove(K, V) - Method in class org.apache.hadoop.hbase.util.PoolMap
- remove(RegionInfo) - Method in class org.apache.hadoop.hbase.quotas.NoOpRegionSizeStore
- remove(RegionInfo) - Method in interface org.apache.hadoop.hbase.quotas.RegionSizeStore
-
Removes the mapping for the given key, returning the value if one exists in the store.
- remove(RegionInfo) - Method in class org.apache.hadoop.hbase.quotas.RegionSizeStoreImpl
- remove(HRegionLocation) - Method in class org.apache.hadoop.hbase.RegionLocations
-
Removes the given location from the list
- remove(MetricRegistryInfo) - Method in class org.apache.hadoop.hbase.metrics.MetricRegistries
-
Decrements the ref count of the MetricRegistry, and removes if ref count == 0.
- remove(TableName) - Method in interface org.apache.hadoop.hbase.TableDescriptors
-
Returns Instance of table descriptor or null if none found.
- remove(TableName) - Method in class org.apache.hadoop.hbase.util.FSTableDescriptors
-
Removes the table descriptor from the local cache and returns it.
- remove(R) - Method in interface org.apache.hadoop.hbase.util.PoolMap.Pool
- remove(TNode, Object, AvlUtil.AvlKeyComparator<TNode>) - Static method in class org.apache.hadoop.hbase.util.AvlUtil.AvlTree
-
Removes the node matching the specified key from the tree
- remove(TNode, Object, AvlUtil.AvlKeyComparator<TNode>, AtomicBoolean) - Static method in class org.apache.hadoop.hbase.util.AvlUtil.AvlTree
-
Removes the node matching the specified key from the tree
- remove(TNode, TNode) - Static method in class org.apache.hadoop.hbase.util.AvlUtil.AvlIterableList
-
Remove a node from the tree
- REMOVE_QUOTA_ON_TABLE_DELETE - Static variable in class org.apache.hadoop.hbase.quotas.MasterQuotasObserver
- REMOVE_QUOTA_ON_TABLE_DELETE_DEFAULT - Static variable in class org.apache.hadoop.hbase.quotas.MasterQuotasObserver
- removeAll(Collection<?>) - Method in class org.apache.hadoop.hbase.ipc.AdaptiveLifoCoDelCallQueue
- removeAll(Collection<?>) - Method in class org.apache.hadoop.hbase.regionserver.CellSet
- removeAll(Collection<?>) - Method in class org.apache.hadoop.hbase.thrift.CallQueue
- removeAll(Collection<?>) - Method in class org.apache.hadoop.hbase.util.SortedList
- removeAllQueues(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueueStorage
-
Remove all the replication queues for the given peer.
- removeAllQueues(String) - Method in class org.apache.hadoop.hbase.replication.TableReplicationQueueStorage
- removeByServer(ServerName) - Method in class org.apache.hadoop.hbase.RegionLocations
-
Returns a new RegionLocations with the locations removed (set to null) which have the destination server as given.
- removeColumnFamily(byte[]) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
- removeCompactedFiles(Collection<HStoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.StoreEngine
- removeCompactedFiles(Collection<HStoreFile>) - Method in interface org.apache.hadoop.hbase.regionserver.StoreFileManager
-
Remove the compacted files
- removeCompactedFiles(Collection<HStoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
- removeConfiguration(String) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
- removeConfiguration(String) - Method in class org.apache.hadoop.hbase.NamespaceDescriptor.Builder
- removeConfiguration(String) - Method in class org.apache.hadoop.hbase.NamespaceDescriptor
-
Remove a config setting represented by the key from the
NamespaceDescriptor.configuration
map - removeConfiguration(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeerConfigBuilder
-
Removes a "raw" configuration property for this replication peer.
- removeConfiguration(String) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
-
Remove a config setting represented by the key from the
RSGroupInfo.configuration
map - removeCoprocessor(String) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
- removeDeadServer(ServerName) - Method in class org.apache.hadoop.hbase.master.DeadServer
-
Called from rpc by operator cleaning up deadserver list.
- removeDeletedRegionFromLoadedFlushedSequenceIds() - Method in class org.apache.hadoop.hbase.master.ServerManager
-
Regions may have been removed between latest persist of FlushedSequenceIds and master abort.
- removeElementsWithNullLocation() - Method in class org.apache.hadoop.hbase.RegionLocations
-
Set the element to null if its getServerName method returns null.
- removeExcludeTableCFsFromReplicationPeerConfig(Map<TableName, List<String>>, ReplicationPeerConfig, String) - Static method in class org.apache.hadoop.hbase.client.replication.ReplicationPeerConfigUtil
- removeExtraHeader(String) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Remove an extra header.
- removeFromBackupSet(String, TableName[]) - Method in interface org.apache.hadoop.hbase.backup.BackupAdmin
-
Remove tables from backup set
- removeFromNamespaceUsage(TableName) - Method in class org.apache.hadoop.hbase.namespace.NamespaceAuditor
- removeHFileRefs(String, List<String>) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueueStorage
-
Remove hfile references from the queue.
- removeHFileRefs(String, List<String>) - Method in class org.apache.hadoop.hbase.replication.TableReplicationQueueStorage
- removeLastSequenceIds(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueueStorage
-
Remove all the max sequence id record for the given peer.
- removeLastSequenceIds(String) - Method in class org.apache.hadoop.hbase.replication.TableReplicationQueueStorage
- removeLastSequenceIds(String, List<String>) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueueStorage
-
Remove the max sequence id record for the given peer and regions.
- removeLastSequenceIds(String, List<String>) - Method in class org.apache.hadoop.hbase.replication.TableReplicationQueueStorage
- removeLastSequenceIdsAndHFileRefsBefore(long) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueueStorage
-
Remove all the last sequence ids and hfile references data which are written before the given timestamp.
- removeLastSequenceIdsAndHFileRefsBefore(long) - Method in class org.apache.hadoop.hbase.replication.TableReplicationQueueStorage
- removeListener() - Method in interface org.apache.hadoop.hbase.coordination.SplitLogWorkerCoordination
-
Deprecated.remove the listener for task changes.
- removeListener() - Method in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination
- removeMetaData(byte[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKMetadata
- removeMetric(String) - Method in interface org.apache.hadoop.hbase.metrics.BaseSource
-
Remove a metric and no longer announce it.
- removeMetric(String) - Method in class org.apache.hadoop.hbase.metrics.BaseSourceImpl
-
Remove a named gauge.
- removeMobFiles(Configuration, FileSystem, TableName, Path, byte[], Collection<HStoreFile>) - Static method in class org.apache.hadoop.hbase.mob.MobUtils
-
Archives the mob files.
- removeNamespaceQuota(String) - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
- removeNamespaceSpaceLimit(String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
-
Creates a
QuotaSettings
object to remove the FileSystem space quota for the given namespace. - removeNonDefaultRegions(Collection<RegionInfo>) - Static method in class org.apache.hadoop.hbase.client.RegionReplicaUtil
-
Removes the non-default replicas from the passed regions collection
- removeParentInMeta(Configuration, RegionInfo) - Static method in class org.apache.hadoop.hbase.util.HBaseFsckRepair
- removePeer(String) - Method in class org.apache.hadoop.hbase.replication.FSReplicationPeerStorage
- removePeer(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeers
- removePeer(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeerStorage
-
Remove a replication peer.
- removePeer(String) - Method in class org.apache.hadoop.hbase.replication.ZKReplicationPeerStorage
- removePeerFromHFileRefs(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueueStorage
-
Remove a peer from hfile reference queue.
- removePeerFromHFileRefs(String) - Method in class org.apache.hadoop.hbase.replication.TableReplicationQueueStorage
- removeQueue(ReplicationQueueId) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueueStorage
-
Remove a replication queue
- removeQueue(ReplicationQueueId) - Method in class org.apache.hadoop.hbase.replication.TableReplicationQueueStorage
- removeQuotesFromByteArray(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Takes a quoted byte array and converts it into an unquoted byte array For example: given a byte array representing 'abc', it returns a byte array representing abc
- removeRegion(RegionInfo) - Method in class org.apache.hadoop.hbase.master.ServerManager
-
Called by delete table and similar to notify the ServerManager that a region was removed.
- removeRegion(HRegion, ServerName) - Method in class org.apache.hadoop.hbase.MockRegionServerServices
- removeRegion(HRegion, ServerName) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
- removeRegion(HRegion, ServerName) - Method in interface org.apache.hadoop.hbase.regionserver.MutableOnlineRegions
-
Removes the given Region from the list of onlineRegions.
- removeRegionFromNamespaceUsage(RegionInfo) - Method in class org.apache.hadoop.hbase.namespace.NamespaceAuditor
- removeRegions(List<RegionInfo>) - Method in class org.apache.hadoop.hbase.master.ServerManager
-
Called by delete table and similar to notify the ServerManager that a region was removed.
- removeRegionSizesForTable(TableName) - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
-
Removes each region size entry where the RegionInfo references the provided TableName.
- removeRegistry() - Method in class org.apache.hadoop.hbase.regionserver.metrics.MetricsTableRequests
- removeRegistry(MetricRegistry) - Static method in class org.apache.hadoop.hbase.coprocessor.MetricsCoprocessor
- removeReplicationPeer(String) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Remove a peer and stop the replication.
- removeReplicationPeer(String) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Remove a peer and stop the replication
- removeReplicationPeer(String) - Method in class org.apache.hadoop.hbase.master.HMaster
- removeReplicationPeer(String) - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Removes a peer and stops the replication
- removeReplicationPeer(RpcController, ReplicationProtos.RemoveReplicationPeerRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- removeReplicationPeerAsync(String) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Remove a replication peer but does not block and wait for it.
- removeReplicationPeerTableCFs(String, Map<TableName, List<String>>) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Remove some table-cfs from config of the specified peer.
- removeReplicationPeerTableCFs(String, Map<TableName, List<String>>) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Remove some table-cfs from config of the specified peer
- removeRSGroup(String) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Remove RegionServer group associated with the given name
- removeRSGroup(String) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Remove RegionServer group associated with the given name
- removeRSGroup(String) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminClient
-
Deprecated.Removes RegionServer group associated with the given name.
- removeRSGroup(String) - Method in interface org.apache.hadoop.hbase.rsgroup.RSGroupInfoManager
-
Remove a region server group.
- removeRSGroup(RpcController, RSGroupAdminProtos.RemoveRSGroupRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- removeServer(Address) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
-
Remove given server from the group.
- removeServerFromDrainList(ServerName) - Method in class org.apache.hadoop.hbase.master.ServerManager
- removeServers(Set<Address>) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminClient
-
Deprecated.Remove decommissioned servers from rsgroup.
- removeServers(Set<Address>) - Method in interface org.apache.hadoop.hbase.rsgroup.RSGroupInfoManager
-
Remove decommissioned servers from rsgroup
- removeServers(RpcController, RSGroupAdminProtos.RemoveServersRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- removeServersFromRSGroup(Set<Address>) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Remove decommissioned servers from group 1.
- removeServersFromRSGroup(Set<Address>) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Remove decommissioned servers from group 1.
- removeShutdownHook(Runnable) - Method in class org.apache.hadoop.hbase.util.ShutdownHookManager
- removeStoreFile(String, Path) - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
Archives the specified store file from the specified family.
- removeStoreFiles(String, Collection<HStoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
Closes and archives the specified store files from the specified family.
- removeTable(TableName) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
-
Deprecated.Since 3.0.0, will be removed in 4.0.0. The rsgroup information will be stored in the configuration of a table so this will be removed.
- removeTableCFsFromReplicationPeerConfig(Map<TableName, List<String>>, ReplicationPeerConfig, String) - Static method in class org.apache.hadoop.hbase.client.replication.ReplicationPeerConfigUtil
- removeTableFromNamespaceQuota(TableName) - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
-
Remove table from namespace quota.
- removeTableSpaceLimit(TableName) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
-
Creates a
QuotaSettings
object to remove the FileSystem space quota for the given table. - removeValue(byte[]) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
- removeValue(String) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
- removeValue(BiPredicate<Bytes, Bytes>) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
- removeValue(Bytes) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
- removeWALRootPath(Path, Configuration) - Static method in class org.apache.hadoop.hbase.util.CommonFSUtils
-
Checks for the presence of the WAL log root path (using the provided conf object) in the given path.
- RENAME_WAL_SUFFIX - Static variable in class org.apache.hadoop.hbase.replication.ReplicationUtils
- renameAndSetModifyTime(FileSystem, Path, Path) - Static method in class org.apache.hadoop.hbase.util.CommonFSUtils
- renameFile(FileSystem, Path, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
- renameRSGroup(String, String) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Rename rsgroup
- renameRSGroup(String, String) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Rename rsgroup
- renameRSGroup(String, String) - Method in interface org.apache.hadoop.hbase.rsgroup.RSGroupInfoManager
-
Rename rsgroup
- renameRSGroup(RpcController, RSGroupAdminProtos.RenameRSGroupRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- renewLease() - Method in class org.apache.hadoop.hbase.client.ClientSideRegionScanner
- renewLease() - Method in interface org.apache.hadoop.hbase.client.ResultScanner
-
Allow the client to renew the scanner's lease on the server.
- renewLease() - Method in class org.apache.hadoop.hbase.client.TableSnapshotScanner
- renewLease(String) - Method in class org.apache.hadoop.hbase.regionserver.LeaseManager
-
Renew a lease
- REOPEN_METRIC_PREFIX - Static variable in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
- reopenAfterFlush() - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
Returns if top of heap has changed (and KeyValueHeap has to try the next KV)
- REPAIR - Enum constant in enum class org.apache.hadoop.hbase.backup.BackupRestoreConstants.BackupCommand
- replace(Object, TNode) - Method in interface org.apache.hadoop.hbase.util.AvlUtil.AvlInsertOrReplace
- replace(Collection<StoreFileInfo>, Collection<StoreFileInfo>) - Method in interface org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileTracker
-
Add new store files and remove compacted store files after compaction.
- replace(K, V) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
- replace(K, V, V) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
- replaceStoreFiles(Collection<HStoreFile>, Collection<HStoreFile>, IOExceptionRunnable, Runnable) - Method in class org.apache.hadoop.hbase.regionserver.StoreEngine
- replay(AdminProtos.ReplicateWALEntryRequest, ExtendedCellScanner) - Method in class org.apache.hadoop.hbase.client.AsyncRegionServerAdmin
- replay(RpcController, AdminProtos.ReplicateWALEntryRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- replay(RpcController, AdminProtos.ReplicateWALEntryRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
Deprecated.Since 3.0.0, will be removed in 4.0.0. Not used any more, put here only for compatibility with old region replica implementation. Now we will use
replicateToReplica
method instead. - REPLAY_BATCH_MUTATE - Enum constant in enum class org.apache.hadoop.hbase.regionserver.Region.Operation
- REPLAY_EVENT - Enum constant in enum class org.apache.hadoop.hbase.regionserver.Region.Operation
- REPLAY_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- REPLAY_QOS - Static variable in class org.apache.hadoop.hbase.HConstants
-
Deprecated.since 3.0.0, will be removed in 4.0.0. DLR has been purged for a long time and region replication has its own 'replay' method.
- replayCompactionMarker(WALProtos.CompactionDescriptor, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
Call to complete a compaction.
- REPLICA_ID - Enum constant in enum class org.apache.hadoop.hbase.hbtop.field.Field
- REPLICA_ID - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
- REPLICA_ID_DELIMITER - Static variable in interface org.apache.hadoop.hbase.client.RegionInfo
- REPLICA_ID_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
- REPLICA_ID_FORMAT - Static variable in interface org.apache.hadoop.hbase.client.RegionInfo
-
to keep appended int's sorted in string format.
- replicate(RegionInfo, List<WAL.Entry>, int, long, long) - Method in interface org.apache.hadoop.hbase.client.AsyncClusterConnection
-
Replicate wal edits to a secondary replica.
- replicate(ReplicationEndpoint.ReplicateContext) - Method in interface org.apache.hadoop.hbase.replication.ReplicationEndpoint
-
Replicate the given set of entries (in the context) to the other cluster.
- replicate(ReplicationEndpoint.ReplicateContext) - Method in class org.apache.hadoop.hbase.replication.VerifyWALEntriesReplicationEndpoint
- replicateAllUserTables() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
- ReplicateContext() - Constructor for class org.apache.hadoop.hbase.replication.ReplicationEndpoint.ReplicateContext
- replicateLogEntries(List<AdminProtos.WALEntry>, ExtendedCellScanner, String, String, String) - Method in interface org.apache.hadoop.hbase.regionserver.ReplicationSinkService
-
Carry on the list of log entries down to the sink
- replicateLogEntries(List<AdminProtos.WALEntry>, ExtendedCellScanner, String, String, String) - Method in class org.apache.hadoop.hbase.replication.ReplicationSinkServiceImpl
- replicateToReplica(RpcController, AdminProtos.ReplicateWALEntryRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- replicateToReplica(RpcController, AdminProtos.ReplicateWALEntryRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
Replay the given changes on a secondary replica
- replicateWALEntry(AdminProtos.ReplicateWALEntryRequest, ExtendedCellScanner, int) - Method in class org.apache.hadoop.hbase.client.AsyncRegionServerAdmin
- replicateWALEntry(RpcController, AdminProtos.ReplicateWALEntryRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- replicateWALEntry(RpcController, AdminProtos.ReplicateWALEntryRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
Replicate WAL entries on the region server.
- REPLICATION - Enum constant in enum class org.apache.hadoop.hbase.ClientMetaTableAccessor.QueryType
- REPLICATION - Static variable in class org.apache.hadoop.hbase.HBaseInterfaceAudience
- REPLICATION_ATTR_NAME - Static variable in class org.apache.hadoop.hbase.replication.ReplicationUtils
- REPLICATION_BARRIER_FAMILY - Static variable in class org.apache.hadoop.hbase.HConstants
-
The replication barrier family
- REPLICATION_BARRIER_FAMILY_STR - Static variable in class org.apache.hadoop.hbase.HConstants
-
The replication barrier family as a string
- REPLICATION_BULKLOAD_ENABLE_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
- REPLICATION_BULKLOAD_ENABLE_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
- REPLICATION_CLUSTER_ID - Static variable in class org.apache.hadoop.hbase.HConstants
-
Replication cluster id of source cluster which uniquely identifies itself with peer cluster
- REPLICATION_CODEC_CONF_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
Configuration key for setting replication codec class name
- REPLICATION_CONF_DIR - Static variable in class org.apache.hadoop.hbase.HConstants
-
Directory where the source cluster file system client configuration are placed which is used by sink cluster to copy HFiles from source cluster file system
- REPLICATION_DROP_ON_DELETED_TABLE_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
Deprecated.since 3.0.0. Will be removed in 4.0.0. Moved it into HBaseInterClusterReplicationEndpoint.
- REPLICATION_MARKER - Static variable in class org.apache.hadoop.hbase.wal.WALEdit
-
Periodically
ReplicationMarkerChore
will create marker edits with family asWALEdit.METAFAMILY
andWALEdit.REPLICATION_MARKER
as qualifier and an empty value. - REPLICATION_PARENT_QUALIFIER - Static variable in class org.apache.hadoop.hbase.replication.ReplicationBarrierFamilyFormat
- REPLICATION_PEER_STORAGE_IMPL - Static variable in class org.apache.hadoop.hbase.replication.ReplicationStorageFactory
- REPLICATION_QOS - Static variable in class org.apache.hadoop.hbase.HConstants
- REPLICATION_QUEUE_DESC - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
- REPLICATION_QUEUE_IMPL - Static variable in class org.apache.hadoop.hbase.replication.ReplicationStorageFactory
- REPLICATION_QUEUE_NAME - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
- REPLICATION_QUEUE_TABLE_NAME - Static variable in class org.apache.hadoop.hbase.replication.ReplicationStorageFactory
- REPLICATION_QUEUE_TABLE_NAME_DEFAULT - Static variable in class org.apache.hadoop.hbase.replication.ReplicationStorageFactory
- REPLICATION_SCOPE - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
- REPLICATION_SCOPE_BYTES - Static variable in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
- REPLICATION_SCOPE_GLOBAL - Static variable in class org.apache.hadoop.hbase.HConstants
-
Scope tag for globally scoped data.
- REPLICATION_SCOPE_LOCAL - Static variable in class org.apache.hadoop.hbase.HConstants
-
Scope tag for locally scoped data.
- REPLICATION_SERVICE_CLASSNAME_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
- REPLICATION_SINK_SERVICE_CLASSNAME - Static variable in class org.apache.hadoop.hbase.HConstants
- REPLICATION_SINK_SERVICE_CLASSNAME_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
- REPLICATION_SOURCE_MAXTHREADS_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
-
Maximum number of threads used by the replication source for shipping edits to the sinks
- REPLICATION_SOURCE_MAXTHREADS_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
Maximum number of threads used by the replication source for shipping edits to the sinks
- REPLICATION_SOURCE_SERVICE_CLASSNAME - Static variable in class org.apache.hadoop.hbase.HConstants
- REPLICATION_SOURCE_SHIPEDITS_TIMEOUT - Static variable in class org.apache.hadoop.hbase.HConstants
-
Configuration key for ReplicationSource shipeEdits timeout
- REPLICATION_SOURCE_SHIPEDITS_TIMEOUT_DFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
- REPLICATION_SOURCE_TOTAL_BUFFER_DFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
- REPLICATION_SOURCE_TOTAL_BUFFER_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
Max total size of buffered entries in all replication peers.
- REPLICATION_TRACKER_IMPL - Static variable in class org.apache.hadoop.hbase.replication.ReplicationFactory
- REPLICATION_WAL_PROVIDER - Static variable in class org.apache.hadoop.hbase.wal.WALFactory
- REPLICATION_WALENTRYFILTER_CONFIG_KEY - Static variable in class org.apache.hadoop.hbase.replication.BaseReplicationEndpoint
- REPLICATION_ZNODE - Static variable in class org.apache.hadoop.hbase.replication.ZKReplicationStorageBase
- REPLICATION_ZNODE_DEFAULT - Static variable in class org.apache.hadoop.hbase.replication.ZKReplicationStorageBase
- org.apache.hadoop.hbase.replication.ReplicationBarrierFamilyFormat - Class in org.apache.hadoop.hbase.replication
-
Helper class for storing replication barriers in family 'rep_barrier' of meta table.
- org.apache.hadoop.hbase.replication.ReplicationBarrierFamilyFormat.ReplicationBarrierResult - Class in org.apache.hadoop.hbase.replication
- org.apache.hadoop.hbase.util.hbck.ReplicationChecker - Class in org.apache.hadoop.hbase.util.hbck
-
Check and fix undeleted replication queues for removed peerId.
- ReplicationChecker(Configuration, ZKWatcher, Connection, HbckErrorReporter) - Constructor for class org.apache.hadoop.hbase.util.hbck.ReplicationChecker
- org.apache.hadoop.hbase.replication.ReplicationEndpoint - Interface in org.apache.hadoop.hbase.replication
-
ReplicationEndpoint is a plugin which implements replication to other HBase clusters, or other systems.
- org.apache.hadoop.hbase.replication.ReplicationEndpoint.Context - Class in org.apache.hadoop.hbase.replication
- org.apache.hadoop.hbase.replication.ReplicationEndpoint.ReplicateContext - Class in org.apache.hadoop.hbase.replication
-
A context for
ReplicationEndpoint.replicate(ReplicateContext)
method. - org.apache.hadoop.hbase.replication.ReplicationException - Exception in org.apache.hadoop.hbase.replication
-
An HBase Replication exception.
- ReplicationException() - Constructor for exception org.apache.hadoop.hbase.replication.ReplicationException
- ReplicationException(String) - Constructor for exception org.apache.hadoop.hbase.replication.ReplicationException
- ReplicationException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.replication.ReplicationException
- ReplicationException(Throwable) - Constructor for exception org.apache.hadoop.hbase.replication.ReplicationException
- org.apache.hadoop.hbase.replication.ReplicationFactory - Class in org.apache.hadoop.hbase.replication
-
A factory class for instantiating replication objects that deal with replication state.
- org.apache.hadoop.hbase.replication.ReplicationGroupOffset - Class in org.apache.hadoop.hbase.replication
- ReplicationGroupOffset(String, long) - Constructor for class org.apache.hadoop.hbase.replication.ReplicationGroupOffset
- org.apache.hadoop.hbase.replication.ReplicationListener - Interface in org.apache.hadoop.hbase.replication
-
The replication listener interface can be implemented if a class needs to subscribe to events generated by the ReplicationTracker.
- org.apache.hadoop.hbase.replication.ReplicationLoadSink - Class in org.apache.hadoop.hbase.replication
-
A HBase ReplicationLoad to present MetricsSink information
- org.apache.hadoop.hbase.replication.ReplicationLoadSink.ReplicationLoadSinkBuilder - Class in org.apache.hadoop.hbase.replication
- org.apache.hadoop.hbase.replication.ReplicationLoadSource - Class in org.apache.hadoop.hbase.replication
-
A HBase ReplicationLoad to present MetricsSource information
- org.apache.hadoop.hbase.replication.ReplicationLoadSource.ReplicationLoadSourceBuilder - Class in org.apache.hadoop.hbase.replication
- org.apache.hadoop.hbase.replication.ReplicationOffsetUtil - Class in org.apache.hadoop.hbase.replication
- org.apache.hadoop.hbase.replication.ReplicationPeer - Interface in org.apache.hadoop.hbase.replication
-
ReplicationPeer manages enabled / disabled state for the peer.
- org.apache.hadoop.hbase.replication.ReplicationPeer.PeerState - Enum Class in org.apache.hadoop.hbase.replication
-
State of the peer, whether it is enabled or not
- org.apache.hadoop.hbase.replication.ReplicationPeerConfig - Class in org.apache.hadoop.hbase.replication
-
A configuration for the replication peer cluster.
- org.apache.hadoop.hbase.replication.ReplicationPeerConfigBuilder - Interface in org.apache.hadoop.hbase.replication
-
For creating
ReplicationPeerConfig
. - org.apache.hadoop.hbase.replication.ReplicationPeerConfigListener - Interface in org.apache.hadoop.hbase.replication
- org.apache.hadoop.hbase.client.replication.ReplicationPeerConfigUtil - Class in org.apache.hadoop.hbase.client.replication
-
Helper for TableCFs Operations.
- org.apache.hadoop.hbase.replication.ReplicationPeerDescription - Class in org.apache.hadoop.hbase.replication
-
The POJO equivalent of ReplicationProtos.ReplicationPeerDescription.
- ReplicationPeerDescription(String, boolean, ReplicationPeerConfig, SyncReplicationState) - Constructor for class org.apache.hadoop.hbase.replication.ReplicationPeerDescription
- org.apache.hadoop.hbase.replication.ReplicationPeerImpl - Class in org.apache.hadoop.hbase.replication
- ReplicationPeerImpl(Configuration, String, ReplicationPeerConfig, boolean, SyncReplicationState, SyncReplicationState) - Constructor for class org.apache.hadoop.hbase.replication.ReplicationPeerImpl
-
Constructor that takes all the objects required to communicate with the specified peer, except for the region server addresses.
- replicationPeerModificationSwitch(boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Enable or disable replication peer modification.
- replicationPeerModificationSwitch(boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Enable or disable replication peer modification.
- replicationPeerModificationSwitch(boolean) - Method in class org.apache.hadoop.hbase.master.HMaster
- replicationPeerModificationSwitch(boolean) - Method in interface org.apache.hadoop.hbase.master.MasterServices
- replicationPeerModificationSwitch(boolean, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Enable or disable replication peer modification.
- replicationPeerModificationSwitch(boolean, boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Enable or disable replication peer modification.
- replicationPeerModificationSwitch(RpcController, ReplicationProtos.ReplicationPeerModificationSwitchRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- org.apache.hadoop.hbase.ReplicationPeerNotFoundException - Exception in org.apache.hadoop.hbase
-
Thrown when a replication peer can not be found
- ReplicationPeerNotFoundException(String) - Constructor for exception org.apache.hadoop.hbase.ReplicationPeerNotFoundException
- org.apache.hadoop.hbase.replication.ReplicationPeers - Class in org.apache.hadoop.hbase.replication
-
This provides an class for maintaining a set of peer clusters.
- org.apache.hadoop.hbase.replication.ReplicationPeerStorage - Interface in org.apache.hadoop.hbase.replication
-
Perform read/write to the replication peer storage.
- org.apache.hadoop.hbase.replication.ReplicationPeerStorageType - Enum Class in org.apache.hadoop.hbase.replication
-
Specify the implementations for
ReplicationPeerStorage
. - org.apache.hadoop.hbase.replication.ReplicationQueueData - Class in org.apache.hadoop.hbase.replication
-
Representing all the information for a replication queue.
- ReplicationQueueData(ReplicationQueueId, ImmutableMap<String, ReplicationGroupOffset>) - Constructor for class org.apache.hadoop.hbase.replication.ReplicationQueueData
- org.apache.hadoop.hbase.replication.ReplicationQueueId - Class in org.apache.hadoop.hbase.replication
- ReplicationQueueId(ServerName, String) - Constructor for class org.apache.hadoop.hbase.replication.ReplicationQueueId
- ReplicationQueueId(ServerName, String, ServerName) - Constructor for class org.apache.hadoop.hbase.replication.ReplicationQueueId
- org.apache.hadoop.hbase.replication.ReplicationQueueInfo - Class in org.apache.hadoop.hbase.replication
-
This class is responsible for the parsing logic for a queue id representing a queue.
- ReplicationQueueInfo(String) - Constructor for class org.apache.hadoop.hbase.replication.ReplicationQueueInfo
-
The passed queueId will be either the id of the peer or the handling story of that queue in the form of id-servername-*
- org.apache.hadoop.hbase.replication.ReplicationQueueStorage - Interface in org.apache.hadoop.hbase.replication
-
Perform read/write to the replication queue storage.
- org.apache.hadoop.hbase.regionserver.ReplicationService - Interface in org.apache.hadoop.hbase.regionserver
-
Gateway to Cluster Replication.
- org.apache.hadoop.hbase.regionserver.ReplicationSinkService - Interface in org.apache.hadoop.hbase.regionserver
-
A sink for a replication stream has to expose this service.
- org.apache.hadoop.hbase.replication.ReplicationSinkServiceImpl - Class in org.apache.hadoop.hbase.replication
- ReplicationSinkServiceImpl() - Constructor for class org.apache.hadoop.hbase.replication.ReplicationSinkServiceImpl
- org.apache.hadoop.hbase.regionserver.ReplicationSourceService - Interface in org.apache.hadoop.hbase.regionserver
-
A source for a replication stream has to expose this service.
- org.apache.hadoop.hbase.replication.ReplicationStorageFactory - Class in org.apache.hadoop.hbase.replication
-
Used to create replication storage(peer, queue) classes.
- org.apache.hadoop.hbase.replication.ReplicationUtils - Class in org.apache.hadoop.hbase.replication
-
Helper class for replication.
- replicationZNode - Variable in class org.apache.hadoop.hbase.replication.ZKReplicationStorageBase
-
The name of the base znode that contains all replication state.
- replicationZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZNodePaths
- report(String) - Method in interface org.apache.hadoop.hbase.util.HbckErrorReporter
-
Deprecated.
- report(HbckErrorReporter) - Method in class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
-
Print a human readable summary of hfile quarantining operations.
- reportBadSink(HBaseReplicationEndpoint.SinkPeer) - Method in class org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint
-
Report a
SinkPeer
as being bad (i.e. - reportCompactionRequestEnd(boolean, int, long) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
- reportCompactionRequestFailure() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
- reportCompactionRequestStart(boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
- reporter - Variable in class org.apache.hadoop.hbase.wal.BoundedRecoveredHFilesOutputSink
- reportError(String) - Method in interface org.apache.hadoop.hbase.util.HbckErrorReporter
-
Deprecated.
- reportError(HbckErrorReporter.ERROR_CODE, String) - Method in interface org.apache.hadoop.hbase.util.HbckErrorReporter
-
Deprecated.
- reportError(HbckErrorReporter.ERROR_CODE, String, HbckTableInfo) - Method in interface org.apache.hadoop.hbase.util.HbckErrorReporter
-
Deprecated.
- reportError(HbckErrorReporter.ERROR_CODE, String, HbckTableInfo, HbckRegionInfo) - Method in interface org.apache.hadoop.hbase.util.HbckErrorReporter
-
Deprecated.
- reportError(HbckErrorReporter.ERROR_CODE, String, HbckTableInfo, HbckRegionInfo, HbckRegionInfo) - Method in interface org.apache.hadoop.hbase.util.HbckErrorReporter
-
Deprecated.
- reportFileArchival(RpcController, RegionServerStatusProtos.FileArchiveNotificationRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- reportFileArchival(RpcController, RegionServerStatusProtos.FileArchiveNotificationRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServicesVersionWrapper
- reportFileArchivalForQuotas(TableName, Collection<Map.Entry<String, Long>>) - Method in class org.apache.hadoop.hbase.MockRegionServerServices
- reportFileArchivalForQuotas(TableName, Collection<Map.Entry<String, Long>>) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
- reportFileArchivalForQuotas(TableName, Collection<Map.Entry<String, Long>>) - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
Reports a collection of files, and their sizes, that belonged to the given
table
were just moved to the archive directory. - REPORTING_INTERVAL_MS - Static variable in class org.apache.hadoop.hbase.util.MultiThreadedAction
- reportMobCompactionEnd(TableName) - Method in class org.apache.hadoop.hbase.master.HMaster
- reportMobCompactionStart(TableName) - Method in class org.apache.hadoop.hbase.master.HMaster
- reportOperationFromWal(long, long, long) - Method in class org.apache.hadoop.hbase.regionserver.ServerNonceManager
-
Reports the operation from WAL during replay.
- reportProcedureDone(RpcController, RegionServerStatusProtos.ReportProcedureDoneRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- reportProcedureDone(RpcController, RegionServerStatusProtos.ReportProcedureDoneRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServicesVersionWrapper
- reportRegionSizesForQuotas(RegionSizeStore) - Method in class org.apache.hadoop.hbase.MockRegionServerServices
- reportRegionSizesForQuotas(RegionSizeStore) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Reports the given map of Regions and their size on the filesystem to the active Master.
- reportRegionSizesForQuotas(RegionSizeStore) - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
Reports the provided Region sizes hosted by this RegionServer to the active Master.
- reportRegionSpaceUse(RpcController, RegionServerStatusProtos.RegionSpaceUseReportRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- reportRegionSpaceUse(RpcController, RegionServerStatusProtos.RegionSpaceUseReportRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServicesVersionWrapper
- reportRegionStateTransition(RegionServerServices.RegionStateTransitionContext) - Method in class org.apache.hadoop.hbase.MockRegionServerServices
- reportRegionStateTransition(RegionServerServices.RegionStateTransitionContext) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
- reportRegionStateTransition(RegionServerServices.RegionStateTransitionContext) - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
Notify master that a handler requests to change a region state
- reportRegionStateTransition(RpcController, RegionServerStatusProtos.ReportRegionStateTransitionRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- reportRegionStateTransition(RpcController, RegionServerStatusProtos.ReportRegionStateTransitionRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServicesVersionWrapper
- reportRSFatalError(RpcController, RegionServerStatusProtos.ReportRSFatalErrorRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- reportRSFatalError(RpcController, RegionServerStatusProtos.ReportRSFatalErrorRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServicesVersionWrapper
- reportSinkSuccess(HBaseReplicationEndpoint.SinkPeer) - Method in class org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint
-
Report that a
SinkPeer
successfully replicated a chunk of data. - reqCleanup - Variable in class org.apache.hadoop.hbase.ipc.ServerCall
- request(Path, Runnable) - Static method in class org.apache.hadoop.hbase.io.hfile.PrefetchExecutor
- REQUEST - Enum constant in enum class org.apache.hadoop.hbase.backup.BackupInfo.BackupPhase
- REQUEST_CAPACITY_UNIT - Enum constant in enum class org.apache.hadoop.hbase.quotas.ThrottleType
-
Throttling based on the read+write capacity unit
- REQUEST_CONTROLLER_IMPL_CONF_KEY - Static variable in class org.apache.hadoop.hbase.client.RequestControllerFactory
- REQUEST_COUNT_PER_SECOND - Enum constant in enum class org.apache.hadoop.hbase.hbtop.field.Field
- REQUEST_KEY - Static variable in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
- REQUEST_MASTER_INTERVAL_SECS - Static variable in class org.apache.hadoop.hbase.regionserver.BootstrapNodeManager
- REQUEST_MASTER_MIN_INTERVAL_SECS - Static variable in class org.apache.hadoop.hbase.regionserver.BootstrapNodeManager
- REQUEST_NUMBER - Enum constant in enum class org.apache.hadoop.hbase.quotas.ThrottleType
-
Throttling based on the number of requests per time-unit
- REQUEST_REGIONSERVER_INTERVAL_SECS - Static variable in class org.apache.hadoop.hbase.regionserver.BootstrapNodeManager
- REQUEST_SIZE - Enum constant in enum class org.apache.hadoop.hbase.quotas.ThrottleType
-
Throttling based on the read+write data size
- REQUEST_SIZE_DESC - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
- REQUEST_SIZE_NAME - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
- requestAttributes - Variable in class org.apache.hadoop.hbase.client.BufferedMutatorParams
- RequestCapacityUnitExceeded - Enum constant in enum class org.apache.hadoop.hbase.quotas.RpcThrottlingException.Type
- requestCompaction() - Method in class org.apache.hadoop.hbase.regionserver.HStore
- requestCompaction(byte[], String, int, boolean, CompactionLifeCycleTracker) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
- requestCompaction(byte[], String, int, boolean, CompactionLifeCycleTracker) - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Request compaction for the given family
- requestCompaction(int, CompactionLifeCycleTracker, User) - Method in class org.apache.hadoop.hbase.regionserver.HStore
- requestCompaction(String, int, boolean, CompactionLifeCycleTracker) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
- requestCompaction(String, int, boolean, CompactionLifeCycleTracker) - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Request compaction on this region.
- requestCompaction(HRegion, String, int, CompactionLifeCycleTracker, User) - Method in class org.apache.hadoop.hbase.regionserver.CompactSplit
- requestCompaction(HRegion, HStore, String, int, CompactionLifeCycleTracker, User) - Method in class org.apache.hadoop.hbase.regionserver.CompactSplit
- requestCompactionInternal(HRegion, HStore, String, int, boolean, CompactionLifeCycleTracker, CompactSplit.CompactionCompleteTracker, User) - Method in class org.apache.hadoop.hbase.regionserver.CompactSplit
- org.apache.hadoop.hbase.client.RequestController - Interface in org.apache.hadoop.hbase.client
-
An interface for client request scheduling algorithm.
- org.apache.hadoop.hbase.client.RequestController.Checker - Interface in org.apache.hadoop.hbase.client
-
Picks up the valid data.
- org.apache.hadoop.hbase.client.RequestController.ReturnCode - Enum Class in org.apache.hadoop.hbase.client
- org.apache.hadoop.hbase.client.RequestControllerFactory - Class in org.apache.hadoop.hbase.client
-
A factory class that constructs an
RequestController
. - RequestControllerFactory() - Constructor for class org.apache.hadoop.hbase.client.RequestControllerFactory
- org.apache.hadoop.hbase.shaded.protobuf.RequestConverter - Class in org.apache.hadoop.hbase.shaded.protobuf
-
Helper utility to build protocol buffer requests, or build components for protocol buffer requests.
- org.apache.hadoop.hbase.hbtop.mode.RequestCountPerSecond - Class in org.apache.hadoop.hbase.hbtop.mode
-
Utility class for calculating request counts per second.
- RequestCountPerSecond() - Constructor for class org.apache.hadoop.hbase.hbtop.mode.RequestCountPerSecond
- requestDelayedFlush(HRegion, long) - Method in interface org.apache.hadoop.hbase.regionserver.FlushRequester
-
Tell the listener the cache needs to be flushed after a delay
- requestDelayedFlush(HRegion, long) - Method in class org.apache.hadoop.hbase.regionserver.MemStoreFlusher
- requestFlush(FlushLifeCycleTracker) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
- requestFlush(FlushLifeCycleTracker) - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Request flush on this region.
- requestFlush(HRegion, List<byte[]>, FlushLifeCycleTracker) - Method in interface org.apache.hadoop.hbase.regionserver.FlushRequester
-
Tell the listener the cache needs to be flushed.
- requestFlush(HRegion, List<byte[]>, FlushLifeCycleTracker) - Method in class org.apache.hadoop.hbase.regionserver.MemStoreFlusher
- requestFlush(HRegion, FlushLifeCycleTracker) - Method in interface org.apache.hadoop.hbase.regionserver.FlushRequester
-
Tell the listener the cache needs to be flushed.
- requestFlush(HRegion, FlushLifeCycleTracker) - Method in class org.apache.hadoop.hbase.regionserver.MemStoreFlusher
- requestLock() - Method in class org.apache.hadoop.hbase.client.locking.EntityLock
-
Sends rpc to the master to request lock.
- requestLock(RpcController, LockServiceProtos.LockRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- requestLogRoll() - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
- requestLogRoll(WALActionsListener.RollRequestReason) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
- RequestQuoter(HttpServletRequest) - Constructor for class org.apache.hadoop.hbase.http.HttpServer.QuotingInputFilter.RequestQuoter
- requestRoll() - Method in class org.apache.hadoop.hbase.wal.AbstractWALRoller.RollController
- requestRollAll() - Method in class org.apache.hadoop.hbase.wal.AbstractWALRoller
- requestSeek(ExtendedCell, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.KeyValueHeap
-
Similar to
KeyValueScanner.seek(org.apache.hadoop.hbase.ExtendedCell)
(orKeyValueScanner.reseek(org.apache.hadoop.hbase.ExtendedCell)
if forward is true) but only does a seek operation after checking that it is really necessary for the row/column combination specified by the kv parameter. - requestSeek(ExtendedCell, boolean, boolean) - Method in interface org.apache.hadoop.hbase.regionserver.KeyValueScanner
-
Similar to
KeyValueScanner.seek(org.apache.hadoop.hbase.ExtendedCell)
(orKeyValueScanner.reseek(org.apache.hadoop.hbase.ExtendedCell)
if forward is true) but only does a seek operation after checking that it is really necessary for the row/column combination specified by the kv parameter. - requestSeek(ExtendedCell, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.NonLazyKeyValueScanner
- requestSeek(ExtendedCell, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.ReversedKeyValueHeap
- requestSeek(ExtendedCell, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.SegmentScanner
- requestSeek(ExtendedCell, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
-
Pretend we have done a seek but don't do it yet, if possible.
- RequestSizeExceeded - Enum constant in enum class org.apache.hadoop.hbase.quotas.RpcThrottlingException.Type
- requestSplit(Region) - Method in class org.apache.hadoop.hbase.regionserver.CompactSplit
- requestSystemCompaction(HRegion, String) - Method in class org.apache.hadoop.hbase.regionserver.CompactSplit
- requestSystemCompaction(HRegion, HStore, String) - Method in class org.apache.hadoop.hbase.regionserver.CompactSplit
- requestSystemCompaction(HRegion, HStore, String, boolean) - Method in class org.apache.hadoop.hbase.regionserver.CompactSplit
- requestTooBigException() - Method in interface org.apache.hadoop.hbase.metrics.ExceptionTrackingSource
- requestTooBigException() - Method in class org.apache.hadoop.hbase.metrics.ExceptionTrackingSourceImpl
- org.apache.hadoop.hbase.exceptions.RequestTooBigException - Exception in org.apache.hadoop.hbase.exceptions
-
Thrown when the size of the rpc request received by the server is too large.
- RequestTooBigException() - Constructor for exception org.apache.hadoop.hbase.exceptions.RequestTooBigException
- RequestTooBigException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.RequestTooBigException
- requirePermission(String, Permission.Action) - Method in class org.apache.hadoop.hbase.HBaseRpcServicesBase
- requireWritingToTmpDirFirst() - Method in class org.apache.hadoop.hbase.regionserver.StoreEngine
-
Whether the implementation of the used storefile tracker requires you to write to temp directory first, i.e, does not allow broken store files under the actual data directory.
- requireWritingToTmpDirFirst() - Method in interface org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileTracker
-
Whether the implementation of this tracker requires you to write to temp directory first, i.e, does not allow broken store files under the actual data directory.
- reseek(byte[]) - Method in interface org.apache.hadoop.hbase.regionserver.RegionScanner
-
Do a reseek to the required row.
- reseek(ExtendedCell) - Method in class org.apache.hadoop.hbase.regionserver.KeyValueHeap
-
This function is identical to the
KeyValueHeap.seek(ExtendedCell)
function except that scanner.seek(seekKey) is changed to scanner.reseek(seekKey). - reseek(ExtendedCell) - Method in interface org.apache.hadoop.hbase.regionserver.KeyValueScanner
-
Reseek the scanner at or after the specified KeyValue.
- reseek(ExtendedCell) - Method in class org.apache.hadoop.hbase.regionserver.ReversedKeyValueHeap
- reseek(ExtendedCell) - Method in class org.apache.hadoop.hbase.regionserver.ReversedStoreScanner
- reseek(ExtendedCell) - Method in class org.apache.hadoop.hbase.regionserver.SegmentScanner
-
Reseek the scanner at or after the specified KeyValue.
- reseek(ExtendedCell) - Method in class org.apache.hadoop.hbase.regionserver.SnapshotSegmentScanner
- reseek(ExtendedCell) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
- reseek(ExtendedCell) - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
- reseek(ExtendedCell) - Method in class org.apache.hadoop.hbase.util.CollectionBackedScanner
- reseekTo(ExtendedCell) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
- reseekTo(ExtendedCell) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
-
Reseek to or just before the passed
cell
. - RESERVED_NAMESPACES - Static variable in class org.apache.hadoop.hbase.NamespaceDescriptor
- RESERVED_NAMESPACES_BYTES - Static variable in class org.apache.hadoop.hbase.NamespaceDescriptor
- reservoirEnabled - Variable in class org.apache.hadoop.hbase.io.ByteBuffAllocator
- org.apache.hadoop.hbase.util.ReservoirSample<T> - Class in org.apache.hadoop.hbase.util
-
The simple version of reservoir sampling implementation.
- ReservoirSample(int) - Constructor for class org.apache.hadoop.hbase.util.ReservoirSample
- reset() - Method in class org.apache.hadoop.hbase.client.ClientCoprocessorRpcController
- reset() - Method in interface org.apache.hadoop.hbase.client.RequestController.Checker
-
Reset the state of the scheduler when completing the iteration of rows.
- reset() - Method in class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
- reset() - Method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
- reset() - Method in class org.apache.hadoop.hbase.filter.ColumnValueFilter
- reset() - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
- reset() - Method in class org.apache.hadoop.hbase.filter.Filter
-
Reset the state of the filter between rows.
- reset() - Method in class org.apache.hadoop.hbase.filter.FilterBase
-
Filters that are purely stateless and do nothing in their reset() methods can inherit this null/empty implementation.
- reset() - Method in class org.apache.hadoop.hbase.filter.FilterList
- reset() - Method in class org.apache.hadoop.hbase.filter.FilterListWithAND
- reset() - Method in class org.apache.hadoop.hbase.filter.FilterListWithOR
- reset() - Method in class org.apache.hadoop.hbase.filter.FilterWrapper
- reset() - Method in class org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
- reset() - Method in class org.apache.hadoop.hbase.filter.FuzzyRowFilter
- reset() - Method in class org.apache.hadoop.hbase.filter.PrefixFilter
- reset() - Method in class org.apache.hadoop.hbase.filter.RandomRowFilter
- reset() - Method in class org.apache.hadoop.hbase.filter.RowFilter
- reset() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
- reset() - Method in class org.apache.hadoop.hbase.filter.SkipFilter
- reset() - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
- reset() - Method in class org.apache.hadoop.hbase.hbtop.terminal.Attributes
- reset() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.Cell
- reset() - Method in class org.apache.hadoop.hbase.io.ByteArrayOutputStream
-
Resets the
pos
field of this byte array output stream to zero. - reset() - Method in class org.apache.hadoop.hbase.io.crypto.aes.AESDecryptor
- reset() - Method in class org.apache.hadoop.hbase.io.crypto.aes.AESEncryptor
- reset() - Method in class org.apache.hadoop.hbase.io.crypto.aes.CommonsCryptoAESDecryptor
- reset() - Method in class org.apache.hadoop.hbase.io.crypto.aes.CommonsCryptoAESEncryptor
- reset() - Method in interface org.apache.hadoop.hbase.io.crypto.Decryptor
-
Reset state, reinitialize with the key and iv
- reset() - Method in interface org.apache.hadoop.hbase.io.crypto.Encryptor
-
Reset state, reinitialize with the key and iv
- reset() - Method in class org.apache.hadoop.hbase.io.FileLink.FileLinkInputStream
- reset() - Method in class org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
- reset() - Method in class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
- reset() - Method in class org.apache.hadoop.hbase.ipc.ServerRpcController
- reset() - Method in class org.apache.hadoop.hbase.nio.ByteBuff
-
Similar to
ByteBuffer
.reset(), ensures that this ByteBuff is reset back to last marked position. - reset() - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
Similar to
ByteBuffer
.reset(), ensures that this MBB is reset back to last marked position. - reset() - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
- reset() - Method in interface org.apache.hadoop.hbase.regionserver.querymatcher.ColumnTracker
-
Resets the Matcher
- reset() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.CompactionScanQueryMatcher
- reset() - Method in interface org.apache.hadoop.hbase.regionserver.querymatcher.DeleteTracker
-
Called between rows.
- reset() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ExplicitColumnTracker
- reset() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.NewVersionBehaviorTracker
- reset() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.NormalUserScanQueryMatcher
- reset() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.RawScanQueryMatcher
- reset() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanDeleteTracker
- reset() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher
- reset() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanWildcardColumnTracker
- reset() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.StripeCompactionScanQueryMatcher
- reset() - Method in class org.apache.hadoop.hbase.types.StructBuilder
-
Reset the sequence of accumulated fields.
- reset() - Static method in class org.apache.hadoop.hbase.util.EnvironmentEdgeManager
-
Resets the managed instance to the default instance:
DefaultEnvironmentEdge
. - resetActive() - Method in class org.apache.hadoop.hbase.regionserver.AbstractMemStore
- resetBuf(int) - Method in class org.apache.hadoop.hbase.codec.BaseDecoder.PBIS
- resetCacheConfig(Configuration) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Enable a basic on-heap cache for these jobs.
- resetCallTimeout() - Method in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCaller
- resetCompression() - Method in enum class org.apache.hadoop.hbase.wal.WALTailingReader.State
- resetCounters() - Static method in class org.apache.hadoop.hbase.SplitLogCounters
-
Deprecated.
- resetErrors() - Method in interface org.apache.hadoop.hbase.util.HbckErrorReporter
-
Deprecated.
- resetInternal() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.NewVersionBehaviorTracker
- resetKVHeap(List<? extends KeyValueScanner>, CellComparator) - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
- resetState() - Method in class org.apache.hadoop.hbase.io.compress.ReusableStreamGzipCodec.ReusableGzipOutputStream
- resetStats() - Method in class org.apache.hadoop.hbase.regionserver.AdaptiveMemStoreCompactionStrategy
- resetStats() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreCompactionStrategy
- resetStats() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreCompactor
- resetTimeOfOldestEdit() - Method in class org.apache.hadoop.hbase.regionserver.AbstractMemStore
- resetTo(long, boolean) - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufWALTailingReader
- resetTo(long, boolean) - Method in interface org.apache.hadoop.hbase.wal.WALTailingReader
-
Reopen the reader to see if there is new data arrives, and also seek(or skip) to the given position.
- Resigned(ServerName) - Constructor for class org.apache.hadoop.hbase.SplitLogTask.Resigned
-
Deprecated.
- RESIGNED - Enum constant in enum class org.apache.hadoop.hbase.regionserver.SplitLogWorker.TaskExecutor.Status
-
Deprecated.
- org.apache.hadoop.hbase.io.hfile.ResizableBlockCache - Interface in org.apache.hadoop.hbase.io.hfile
-
BlockCache which is resizable.
- resizeQueues(Configuration) - Method in class org.apache.hadoop.hbase.ipc.RpcExecutor
-
Update current soft limit for executor's call queues
- resolve(ExtendedCell, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HMobStore
-
Reads the cell from the mob file, and the read point does not count.
- resolve(ExtendedCell, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HMobStore
-
Reads the cell from the mob file with readEmptyValueOnMobCellMiss
- resolve(ExtendedCell, boolean, long, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HMobStore
-
Reads the cell from the mob file.
- RESOURCE_SCHEME - Static variable in class org.apache.hadoop.hbase.io.compress.DictionaryCache
- org.apache.hadoop.hbase.rest.ResourceBase - Class in org.apache.hadoop.hbase.rest
- ResourceBase() - Constructor for class org.apache.hadoop.hbase.rest.ResourceBase
- responder - Variable in class org.apache.hadoop.hbase.ipc.SimpleRpcServer
-
Deprecated.
- response - Variable in class org.apache.hadoop.hbase.ipc.ServerCall
-
Chain of buffers to send as response.
- org.apache.hadoop.hbase.rest.client.Response - Class in org.apache.hadoop.hbase.rest.client
-
The HTTP result code, response headers, and body of an HTTP response.
- Response(int) - Constructor for class org.apache.hadoop.hbase.rest.client.Response
-
Constructor
- Response(int, Header[]) - Constructor for class org.apache.hadoop.hbase.rest.client.Response
-
Constructor
- Response(int, Header[], byte[]) - Constructor for class org.apache.hadoop.hbase.rest.client.Response
-
Constructor
- Response(int, Header[], HttpResponse, InputStream) - Constructor for class org.apache.hadoop.hbase.rest.client.Response
-
Constructor.
- RESPONSE_SIZE_DESC - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
- RESPONSE_SIZE_NAME - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
- org.apache.hadoop.hbase.shaded.protobuf.ResponseConverter - Class in org.apache.hadoop.hbase.shaded.protobuf
-
Helper utility to build protocol buffer responses, or retrieve data from protocol buffer responses.
- org.apache.hadoop.hbase.http.jersey.ResponseEntityMapper - Class in org.apache.hadoop.hbase.http.jersey
-
Generate a uniform response wrapper around the Entity returned from the resource.
- ResponseEntityMapper() - Constructor for class org.apache.hadoop.hbase.http.jersey.ResponseEntityMapper
- REST_AUTHENTICATION_PRINCIPAL - Static variable in interface org.apache.hadoop.hbase.rest.Constants
- REST_AUTHENTICATION_TYPE - Static variable in interface org.apache.hadoop.hbase.rest.Constants
- REST_CLIENT_CONN_TIMEOUT - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
Configuration parameter to set rest client connection timeout
- REST_CLIENT_SOCKET_TIMEOUT - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
Configuration parameter to set rest client socket timeout
- REST_CONNECTOR_ACCEPT_QUEUE_SIZE - Static variable in interface org.apache.hadoop.hbase.rest.Constants
- REST_DNS_INTERFACE - Static variable in interface org.apache.hadoop.hbase.rest.Constants
- REST_DNS_NAMESERVER - Static variable in interface org.apache.hadoop.hbase.rest.Constants
- REST_KERBEROS_PRINCIPAL - Static variable in interface org.apache.hadoop.hbase.rest.Constants
- REST_KEYTAB_FILE - Static variable in interface org.apache.hadoop.hbase.rest.Constants
- REST_SCANNERCACHE_EXPIRE_TIME - Static variable in interface org.apache.hadoop.hbase.rest.Constants
- REST_SCANNERCACHE_SIZE - Static variable in interface org.apache.hadoop.hbase.rest.Constants
- REST_SERVER - Static variable in class org.apache.hadoop.hbase.rest.RESTServer
- REST_SSL_ENABLED - Static variable in interface org.apache.hadoop.hbase.rest.Constants
- REST_SSL_EXCLUDE_CIPHER_SUITES - Static variable in interface org.apache.hadoop.hbase.rest.Constants
- REST_SSL_EXCLUDE_PROTOCOLS - Static variable in interface org.apache.hadoop.hbase.rest.Constants
- REST_SSL_INCLUDE_CIPHER_SUITES - Static variable in interface org.apache.hadoop.hbase.rest.Constants
- REST_SSL_INCLUDE_PROTOCOLS - Static variable in interface org.apache.hadoop.hbase.rest.Constants
- REST_SSL_KEYSTORE_KEYPASSWORD - Static variable in interface org.apache.hadoop.hbase.rest.Constants
- REST_SSL_KEYSTORE_PASSWORD - Static variable in interface org.apache.hadoop.hbase.rest.Constants
- REST_SSL_KEYSTORE_STORE - Static variable in interface org.apache.hadoop.hbase.rest.Constants
- REST_SSL_KEYSTORE_TYPE - Static variable in interface org.apache.hadoop.hbase.rest.Constants
- REST_SSL_TRUSTSTORE_PASSWORD - Static variable in interface org.apache.hadoop.hbase.rest.Constants
- REST_SSL_TRUSTSTORE_STORE - Static variable in interface org.apache.hadoop.hbase.rest.Constants
- REST_SSL_TRUSTSTORE_TYPE - Static variable in interface org.apache.hadoop.hbase.rest.Constants
- REST_THREAD_POOL_TASK_QUEUE_SIZE - Static variable in interface org.apache.hadoop.hbase.rest.Constants
- REST_THREAD_POOL_THREAD_IDLE_TIMEOUT - Static variable in interface org.apache.hadoop.hbase.rest.Constants
- REST_THREAD_POOL_THREADS_MAX - Static variable in interface org.apache.hadoop.hbase.rest.Constants
- REST_THREAD_POOL_THREADS_MIN - Static variable in interface org.apache.hadoop.hbase.rest.Constants
- restart(byte[]) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
-
Restart from survivable exceptions by creating a new scanner.
- restart(byte[]) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
-
Restart from survivable exceptions by creating a new scanner.
- restart(byte[]) - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReader
-
Restart from survivable exceptions by creating a new scanner.
- restart(byte[]) - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReaderImpl
-
Restart from survivable exceptions by creating a new scanner.
- restartHBaseCluster(int) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Starts the hbase cluster up again after shutting it down previously in a test.
- restartHBaseCluster(int, List<Integer>) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- restartHBaseCluster(StartMiniClusterOption) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- restartWriterThreadsIfNeeded() - Method in class org.apache.hadoop.hbase.wal.BoundedRecoveredHFilesOutputSink
- org.apache.hadoop.hbase.rest.RESTDumpServlet - Class in org.apache.hadoop.hbase.rest
- RESTDumpServlet() - Constructor for class org.apache.hadoop.hbase.rest.RESTDumpServlet
- restore(RestoreRequest) - Method in interface org.apache.hadoop.hbase.backup.BackupAdmin
-
Restore backup
- RESTORE_DIR_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl
- RESTORE_DIRS_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.MultiTableSnapshotInputFormatImpl
- restoreClusterMetrics(ClusterMetrics) - Method in class org.apache.hadoop.hbase.HBaseCluster
-
Deprecated.Restores the cluster to given state if this is a real cluster, otherwise does nothing.
- org.apache.hadoop.hbase.backup.RestoreDriver - Class in org.apache.hadoop.hbase.backup
-
Command-line entry point for restore operation
- RestoreDriver() - Constructor for class org.apache.hadoop.hbase.backup.RestoreDriver
- restoreEdit(HStore, ExtendedCell, MemStoreSizing) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Used by tests
- restoreHdfsRegions() - Method in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper
-
Restore the on-disk table to a specified snapshot state.
- restoreInitialStatus() - Method in class org.apache.hadoop.hbase.HBaseCluster
-
Deprecated.Restores the cluster to it's initial state if this is a real cluster, otherwise does nothing.
- org.apache.hadoop.hbase.backup.RestoreJob - Interface in org.apache.hadoop.hbase.backup
-
Restore operation job interface Concrete implementation is provided by backup provider, see
BackupRestoreFactory
- RestoreMetaChanges(TableDescriptor, Map<String, Pair<String, String>>) - Constructor for class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper.RestoreMetaChanges
- org.apache.hadoop.hbase.backup.RestoreRequest - Class in org.apache.hadoop.hbase.backup
-
POJO class for restore request
- org.apache.hadoop.hbase.backup.RestoreRequest.Builder - Class in org.apache.hadoop.hbase.backup
- restoreSnapshot(String) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Restore the specified snapshot on the original table.
- restoreSnapshot(String) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Restore the specified snapshot on the original table.
- restoreSnapshot(String, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Restore the specified snapshot on the original table.
- restoreSnapshot(String, boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Restore the specified snapshot on the original table.
- restoreSnapshot(String, boolean, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Restore the specified snapshot on the original table.
- restoreSnapshot(String, boolean, boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Restore the specified snapshot on the original table.
- restoreSnapshot(SnapshotProtos.SnapshotDescription, long, long, boolean, String) - Method in class org.apache.hadoop.hbase.master.HMaster
- restoreSnapshot(RpcController, MasterProtos.RestoreSnapshotRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
Execute Restore/Clone snapshot operation.
- restoreSnapshotAcl(SnapshotProtos.SnapshotDescription, TableName, Configuration) - Static method in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper
- org.apache.hadoop.hbase.snapshot.RestoreSnapshotException - Exception in org.apache.hadoop.hbase.snapshot
-
Thrown when a snapshot could not be restored due to a server-side error when restoring it.
- RestoreSnapshotException(String) - Constructor for exception org.apache.hadoop.hbase.snapshot.RestoreSnapshotException
- RestoreSnapshotException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.snapshot.RestoreSnapshotException
- RestoreSnapshotException(String, Throwable, SnapshotDescription) - Constructor for exception org.apache.hadoop.hbase.snapshot.RestoreSnapshotException
- RestoreSnapshotException(String, SnapshotDescription) - Constructor for exception org.apache.hadoop.hbase.snapshot.RestoreSnapshotException
- org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper - Class in org.apache.hadoop.hbase.snapshot
-
Helper to Restore/Clone a Snapshot
- RestoreSnapshotHelper(Configuration, FileSystem, SnapshotManifest, TableDescriptor, Path, ForeignExceptionDispatcher, MonitoredTask) - Constructor for class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper
- RestoreSnapshotHelper(Configuration, FileSystem, SnapshotManifest, TableDescriptor, Path, ForeignExceptionDispatcher, MonitoredTask, boolean) - Constructor for class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper
- org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper.RestoreMetaChanges - Class in org.apache.hadoop.hbase.snapshot
-
Describe the set of operations needed to update hbase:meta after restore.
- restoreSnapshots(Configuration, Map<String, Path>, FileSystem) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableSnapshotInputFormatImpl
-
Restore each (snapshot name, restore directory) pair in snapshotToDir
- RESTRICTION_TYPE_DELIMITED_KEY_PREFIX - Static variable in class org.apache.hadoop.hbase.regionserver.RegionSplitRestriction
- RESTRICTION_TYPE_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.RegionSplitRestriction
- RESTRICTION_TYPE_KEY_PREFIX - Static variable in class org.apache.hadoop.hbase.regionserver.RegionSplitRestriction
- RESTRICTION_TYPE_NONE - Static variable in class org.apache.hadoop.hbase.regionserver.RegionSplitRestriction
- org.apache.hadoop.hbase.rest.RESTServer - Class in org.apache.hadoop.hbase.rest
-
Main class for launching REST gateway as a servlet hosted by Jetty.
- RESTServer(Configuration) - Constructor for class org.apache.hadoop.hbase.rest.RESTServer
- org.apache.hadoop.hbase.rest.RESTServlet - Class in org.apache.hadoop.hbase.rest
-
Singleton class encapsulating global REST servlet state and functions.
- org.apache.hadoop.hbase.rest.RESTServletContainer - Class in org.apache.hadoop.hbase.rest
-
REST servlet container.
- RESTServletContainer(ResourceConfig) - Constructor for class org.apache.hadoop.hbase.rest.RESTServletContainer
- org.apache.hadoop.hbase.rest.RestUtil - Class in org.apache.hadoop.hbase.rest
- resubmitTask(String, SplitLogManager.Task, SplitLogManager.ResubmitDirective) - Method in interface org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination
-
Deprecated.Resubmit the task in case if found unassigned or failed
- resubmitTask(String, SplitLogManager.Task, SplitLogManager.ResubmitDirective) - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
- resubmitThresholdReached - Variable in class org.apache.hadoop.hbase.master.SplitLogManager.Task
-
Deprecated.
- org.apache.hadoop.hbase.client.Result - Class in org.apache.hadoop.hbase.client
-
Single row result of a
Get
orScan
query. - Result() - Constructor for class org.apache.hadoop.hbase.client.Result
-
Creates an empty Result w/ no KeyValue payload; returns null if you call
Result.rawCells()
. - Result(WALTailingReader.State, WAL.Entry, long) - Constructor for class org.apache.hadoop.hbase.wal.WALTailingReader.Result
- org.apache.hadoop.hbase.rest.ResultGenerator - Class in org.apache.hadoop.hbase.rest
- ResultGenerator() - Constructor for class org.apache.hadoop.hbase.rest.ResultGenerator
- org.apache.hadoop.hbase.client.ResultScanner - Interface in org.apache.hadoop.hbase.client
-
Interface for client-side scanning.
- ResultScannerWrapper(ResultScanner, boolean) - Constructor for class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler.ResultScannerWrapper
- org.apache.hadoop.hbase.mapreduce.ResultSerialization - Class in org.apache.hadoop.hbase.mapreduce
- ResultSerialization() - Constructor for class org.apache.hadoop.hbase.mapreduce.ResultSerialization
- org.apache.hadoop.hbase.client.ResultStatsUtil - Class in org.apache.hadoop.hbase.client
-
Statistics update about a server/region
- resume() - Method in interface org.apache.hadoop.hbase.client.AdvancedScanResultConsumer.ScanResumer
-
Resume the scan.
- resumeRegionServer(int) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.Resume the specified region server
- resumeRegionServer(ServerName) - Method in class org.apache.hadoop.hbase.HBaseCluster
-
Deprecated.Resume the region server
- resumeRegionServer(ServerName) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.
- retain() - Method in interface org.apache.hadoop.hbase.io.hfile.Cacheable
-
Increase its reference count, and only when no reference we can free the object's memory.
- retain() - Method in class org.apache.hadoop.hbase.io.hfile.ExclusiveMemHFileBlock
- retain() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
- retain() - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
- retain() - Method in class org.apache.hadoop.hbase.nio.RefCnt
- retain() - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
- retain(int) - Method in interface org.apache.hadoop.hbase.nio.HBaseReferenceCounted
- retain(int) - Method in class org.apache.hadoop.hbase.nio.RefCnt
- retainAll(Collection<?>) - Method in class org.apache.hadoop.hbase.ipc.AdaptiveLifoCoDelCallQueue
- retainAll(Collection<?>) - Method in class org.apache.hadoop.hbase.regionserver.CellSet
- retainAll(Collection<?>) - Method in class org.apache.hadoop.hbase.thrift.CallQueue
- retainAll(Collection<?>) - Method in class org.apache.hadoop.hbase.util.SortedList
- retainAssignment(Map<RegionInfo, ServerName>, List<ServerName>) - Method in interface org.apache.hadoop.hbase.master.LoadBalancer
-
Assign regions to the previously hosting region server
- retainAssignment(Map<RegionInfo, ServerName>, List<ServerName>) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupBasedLoadBalancer
- retainByWAL() - Method in class org.apache.hadoop.hbase.ipc.ServerCall
- rethrow(Throwable) - Static method in class org.apache.hadoop.hbase.util.FutureUtils
-
If we could propagate the given
error
directly, we will fill the stack trace with the current thread's stack trace so it is easier to trace where is the exception thrown. - rethrowException() - Method in class org.apache.hadoop.hbase.errorhandling.ForeignExceptionDispatcher
- rethrowException() - Method in interface org.apache.hadoop.hbase.errorhandling.ForeignExceptionSnare
-
Rethrow an exception currently held by the
ForeignExceptionSnare
. - rethrowExceptionIfFailed() - Method in interface org.apache.hadoop.hbase.master.SnapshotSentinel
-
Rethrow the exception returned by
SnapshotSentinel.getExceptionIfFailed()
. - rethrowIfInterrupt(Throwable) - Static method in class org.apache.hadoop.hbase.util.ExceptionUtil
-
Throw InterruptedIOException if t was an interruption, nothing otherwise.
- RETRIES_NUMBER - Static variable in class org.apache.hadoop.hbase.regionserver.regionreplication.RegionReplicationSink
- RETRIES_NUMBER_DEFAULT - Static variable in class org.apache.hadoop.hbase.regionserver.regionreplication.RegionReplicationSink
- org.apache.hadoop.hbase.client.RetriesExhaustedException - Exception in org.apache.hadoop.hbase.client
-
Exception thrown by HTable methods when an attempt to do something (like commit changes) fails after a bunch of retries.
- RetriesExhaustedException(int, List<RetriesExhaustedException.ThrowableWithExtraContext>) - Constructor for exception org.apache.hadoop.hbase.client.RetriesExhaustedException
-
Create a new RetriesExhaustedException from the list of prior failures.
- RetriesExhaustedException(String) - Constructor for exception org.apache.hadoop.hbase.client.RetriesExhaustedException
- RetriesExhaustedException(String, int, List<Throwable>) - Constructor for exception org.apache.hadoop.hbase.client.RetriesExhaustedException
-
Create a new RetriesExhaustedException from the list of prior failures.
- RetriesExhaustedException(String, IOException) - Constructor for exception org.apache.hadoop.hbase.client.RetriesExhaustedException
- org.apache.hadoop.hbase.client.RetriesExhaustedException.ThrowableWithExtraContext - Class in org.apache.hadoop.hbase.client
-
Data structure that allows adding more info around Throwable incident.
- org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException - Exception in org.apache.hadoop.hbase.client
-
This subclass of
RetriesExhaustedException
is thrown when we have more information about which rows were causing which exceptions on what servers. - RetriesExhaustedWithDetailsException(String) - Constructor for exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
- RetriesExhaustedWithDetailsException(String, IOException) - Constructor for exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
- RetriesExhaustedWithDetailsException(List<Throwable>, List<Row>, List<String>) - Constructor for exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
- retrieveGetCounterWithStringsParams(TaskAttemptContext) - Static method in class org.apache.hadoop.hbase.mapreduce.TableRecordReaderImpl
-
Deprecated.since 2.4.0 and 2.3.2, will be removed in 4.0.0
- RETRY_ATTEMPTS_KEY - Static variable in class org.apache.hadoop.hbase.chaos.ChaosConstants
- RETRY_BACKOFF - Static variable in class org.apache.hadoop.hbase.HConstants
-
Retrying we multiply hbase.client.pause setting by what we have in this array until we run out of array items.
- RETRY_SLEEP_INTERVAL_KEY - Static variable in class org.apache.hadoop.hbase.chaos.ChaosConstants
- RetryConfig() - Constructor for class org.apache.hadoop.hbase.util.RetryCounter.RetryConfig
- RetryConfig(int, long, long, TimeUnit, RetryCounter.BackoffPolicy) - Constructor for class org.apache.hadoop.hbase.util.RetryCounter.RetryConfig
- org.apache.hadoop.hbase.util.RetryCounter - Class in org.apache.hadoop.hbase.util
-
Operation retry accounting.
- RetryCounter(int, long, TimeUnit) - Constructor for class org.apache.hadoop.hbase.util.RetryCounter
- RetryCounter(RetryCounter.RetryConfig) - Constructor for class org.apache.hadoop.hbase.util.RetryCounter
- org.apache.hadoop.hbase.util.RetryCounter.BackoffPolicy - Class in org.apache.hadoop.hbase.util
-
Policy for calculating sleeping intervals between retry attempts
- org.apache.hadoop.hbase.util.RetryCounter.ExponentialBackoffPolicy - Class in org.apache.hadoop.hbase.util
- org.apache.hadoop.hbase.util.RetryCounter.ExponentialBackoffPolicyWithLimit - Class in org.apache.hadoop.hbase.util
- org.apache.hadoop.hbase.util.RetryCounter.RetryConfig - Class in org.apache.hadoop.hbase.util
-
Configuration for a retry counter
- org.apache.hadoop.hbase.util.RetryCounterFactory - Class in org.apache.hadoop.hbase.util
- RetryCounterFactory(int) - Constructor for class org.apache.hadoop.hbase.util.RetryCounterFactory
- RetryCounterFactory(int, int) - Constructor for class org.apache.hadoop.hbase.util.RetryCounterFactory
- RetryCounterFactory(int, int, int) - Constructor for class org.apache.hadoop.hbase.util.RetryCounterFactory
- RetryCounterFactory(RetryCounter.RetryConfig) - Constructor for class org.apache.hadoop.hbase.util.RetryCounterFactory
- org.apache.hadoop.hbase.RetryImmediatelyException - Exception in org.apache.hadoop.hbase
- RetryImmediatelyException(String) - Constructor for exception org.apache.hadoop.hbase.RetryImmediatelyException
- returnCompressor(Compressor) - Method in enum class org.apache.hadoop.hbase.io.compress.Compression.Algorithm
- returnDecompressor(Decompressor) - Method in enum class org.apache.hadoop.hbase.io.compress.Compression.Algorithm
- returnToNextScreen() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.FilterDisplayModeScreenPresenter
- returnToNextScreen() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.InputModeScreenPresenter
- returnToNextScreen() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.MessageModeScreenPresenter
- ReusableGzipOutputStream(OutputStream) - Constructor for class org.apache.hadoop.hbase.io.compress.ReusableStreamGzipCodec.ReusableGzipOutputStream
- org.apache.hadoop.hbase.io.compress.ReusableStreamGzipCodec - Class in org.apache.hadoop.hbase.io.compress
-
Fixes an inefficiency in Hadoop's Gzip codec, allowing to reuse compression streams.
- ReusableStreamGzipCodec() - Constructor for class org.apache.hadoop.hbase.io.compress.ReusableStreamGzipCodec
- org.apache.hadoop.hbase.io.compress.ReusableStreamGzipCodec.ReusableGzipOutputStream - Class in org.apache.hadoop.hbase.io.compress
-
A bridge that wraps around a DeflaterOutputStream to make it a CompressionOutputStream.
- reversed - Variable in class org.apache.hadoop.hbase.filter.Filter
- org.apache.hadoop.hbase.regionserver.ReversedKeyValueHeap - Class in org.apache.hadoop.hbase.regionserver
-
ReversedKeyValueHeap is used for supporting reversed scanning.
- ReversedKeyValueHeap(List<? extends KeyValueScanner>, CellComparator) - Constructor for class org.apache.hadoop.hbase.regionserver.ReversedKeyValueHeap
- org.apache.hadoop.hbase.regionserver.ReversedMobStoreScanner - Class in org.apache.hadoop.hbase.regionserver
-
ReversedMobStoreScanner extends from ReversedStoreScanner, and is used to support reversed scanning in both the memstore and the MOB store.
- reversedNextCellHint - Variable in class org.apache.hadoop.hbase.filter.PrefixFilter
- org.apache.hadoop.hbase.regionserver.ReversedStoreScanner - Class in org.apache.hadoop.hbase.regionserver
-
ReversedStoreScanner extends from StoreScanner, and is used to support reversed scanning.
- ReversedStoreScanner(Scan, ScanInfo, NavigableSet<byte[]>, List<? extends KeyValueScanner>) - Constructor for class org.apache.hadoop.hbase.regionserver.ReversedStoreScanner
-
Constructor for testing.
- ReversedStoreScanner(HStore, ScanInfo, Scan, NavigableSet<byte[]>, long) - Constructor for class org.apache.hadoop.hbase.regionserver.ReversedStoreScanner
-
Opens a scanner across memstore, snapshot, and all StoreFiles.
- ReverseTab - Enum constant in enum class org.apache.hadoop.hbase.hbtop.terminal.KeyPress.Type
- revoke(UserPermission) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Revokes user specific permissions
- revoke(UserPermission) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Revokes user specific permissions
- revoke(TAccessControlEntity) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
- revoke(RpcController, AccessControlProtos.RevokeRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- rewind() - Method in interface org.apache.hadoop.hbase.io.encoding.DataBlockEncoder.EncodedSeeker
-
Set position to beginning of given block
- rewind() - Method in class org.apache.hadoop.hbase.io.encoding.RowIndexSeekerV1
- rewind() - Method in class org.apache.hadoop.hbase.nio.ByteBuff
-
Rewinds this ByteBuff and the position is set to 0
- rewind() - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
Rewinds this MBB and the position is set to 0
- rewind() - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
- rewindThenToList(ByteBuffer, boolean, boolean) - Static method in class org.apache.hadoop.hbase.KeyValueTestUtil
- RING_BUFFER_SLOT_COUNT - Static variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
- RIT_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
- RIT_COUNT_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
- RIT_COUNT_OVER_THRESHOLD_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
- RIT_COUNT_OVER_THRESHOLD_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
- RIT_DURATION_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
- RIT_DURATION_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
- RIT_OLDEST_AGE_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
- RIT_OLDEST_AGE_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
- rLength - Variable in class org.apache.hadoop.hbase.ExtendedCellBuilderImpl
- RMI_CONNECTOR_PORT_CONF_KEY - Static variable in class org.apache.hadoop.hbase.JMXListener
- RMI_REGISTRY_PORT_CONF_KEY - Static variable in class org.apache.hadoop.hbase.JMXListener
- RNG_ALGORITHM_KEY - Static variable in class org.apache.hadoop.hbase.io.crypto.Cipher
- RNG_PROVIDER_KEY - Static variable in class org.apache.hadoop.hbase.io.crypto.Cipher
- rOffset - Variable in class org.apache.hadoop.hbase.ExtendedCellBuilderImpl
- ROLL_ON_SYNC_TIME_MS - Static variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
- ROLL_REQUESTED - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
- ROLL_REQUESTED_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
- rollbackState(MasterProcedureEnv, MasterProcedureProtos.ModifyStoreFileTrackerState) - Method in class org.apache.hadoop.hbase.regionserver.storefiletracker.ModifyStoreFileTrackerProcedure
- ROLLED - Enum constant in enum class org.apache.hadoop.hbase.regionserver.wal.WALEventTrackerListener.WalState
- ROLLING - Enum constant in enum class org.apache.hadoop.hbase.regionserver.wal.WALEventTrackerListener.WalState
- org.apache.hadoop.hbase.util.RollingStatCalculator - Class in org.apache.hadoop.hbase.util
-
This class maintains mean and variation for any sequence of input provided to it.
- RollingStatCalculator(int) - Constructor for class org.apache.hadoop.hbase.util.RollingStatCalculator
-
Creates a RollingStatCalculator with given number of rolling periods.
- rollMetricsPeriod() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
- rollMetricsPeriod() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
- rollOnSyncNs - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
The slow sync will be logged; the very slow sync will cause the WAL to be rolled.
- rollRequested - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
- rollWal(long) - Method in class org.apache.hadoop.hbase.wal.AbstractWALRoller.RollController
- rollWALWriter(ServerName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Roll the log writer.
- rollWALWriter(ServerName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Roll the log writer.
- rollWALWriter(AdminProtos.RollWALWriterRequest) - Method in class org.apache.hadoop.hbase.client.AsyncRegionServerAdmin
- rollWALWriter(RpcController, AdminProtos.RollWALWriterRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- rollWALWriter(RpcController, AdminProtos.RollWALWriterRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
Roll the WAL writer of the region server.
- rollWriter() - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
- rollWriter() - Method in interface org.apache.hadoop.hbase.wal.WAL
-
Roll the log writer.
- rollWriter(boolean) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
- rollWriter(boolean) - Method in interface org.apache.hadoop.hbase.wal.WAL
-
Roll the log writer.
- rollWriterLock - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
This lock makes sure only one log roll runs at a time.
- ROOT_INDEX - Enum constant in enum class org.apache.hadoop.hbase.io.hfile.BlockType
-
Root index block, also used for the single-level meta index, version 2
- rootBlockContainingKey(Cell) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileIndexBlockEncoder.EncodedSeeker
- rootBlockContainingKey(Cell) - Method in class org.apache.hadoop.hbase.io.hfile.NoOpIndexBlockEncoder.NoOpEncodedSeeker
- rootCount - Variable in class org.apache.hadoop.hbase.io.hfile.NoOpIndexBlockEncoder.NoOpEncodedSeeker
- org.apache.hadoop.hbase.rest.RootResource - Class in org.apache.hadoop.hbase.rest
- RootResource() - Constructor for class org.apache.hadoop.hbase.rest.RootResource
-
Constructor
- org.apache.hadoop.hbase.util.RotateFile - Class in org.apache.hadoop.hbase.util
-
A file storage which supports atomic update through two files, i.e, rotating.
- RotateFile(FileSystem, Path, String, long) - Constructor for class org.apache.hadoop.hbase.util.RotateFile
-
Constructs a new RotateFile object with the given parameters.
- roundInt2(int) - Static method in class org.apache.hadoop.hbase.io.compress.CompressionUtil
-
Round up to the next power of two, unless the value would become negative (ints are signed), in which case just return Integer.MAX_VALUE.
- RoundRobin - Enum constant in enum class org.apache.hadoop.hbase.util.PoolMap.PoolType
- roundRobinAssignment(List<RegionInfo>, List<ServerName>) - Method in class org.apache.hadoop.hbase.favored.FavoredNodeLoadBalancer
- roundRobinAssignment(List<RegionInfo>, List<ServerName>) - Method in interface org.apache.hadoop.hbase.master.LoadBalancer
-
Perform a Round Robin assignment of regions.
- roundRobinAssignment(List<RegionInfo>, List<ServerName>) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupBasedLoadBalancer
- org.apache.hadoop.hbase.mapreduce.RoundRobinTableInputFormat - Class in org.apache.hadoop.hbase.mapreduce
-
Process the return from super-class
TableInputFormat
(TIF) so as to undo any clumping ofInputSplit
s around RegionServers. - RoundRobinTableInputFormat() - Constructor for class org.apache.hadoop.hbase.mapreduce.RoundRobinTableInputFormat
- row - Variable in class org.apache.hadoop.hbase.client.Mutation
- row - Variable in class org.apache.hadoop.hbase.ExtendedCellBuilderImpl
- org.apache.hadoop.hbase.client.Row - Interface in org.apache.hadoop.hbase.client
-
Has a row.
- ROW - Enum constant in enum class org.apache.hadoop.hbase.regionserver.BloomType
-
Bloom enabled with Table row as Key
- ROW - Enum constant in enum class org.apache.hadoop.hbase.regionserver.wal.CompressionContext.DictionaryIndex
- ROW_INDEX_V1 - Enum constant in enum class org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
- ROW_KEY_OFFSET - Static variable in class org.apache.hadoop.hbase.KeyValue
- ROW_KEYS_PARAM_NAME - Static variable in interface org.apache.hadoop.hbase.rest.Constants
- ROW_LENGTH - Static variable in class org.apache.hadoop.hbase.PerformanceEvaluation
- ROW_LENGTH_SIZE - Static variable in class org.apache.hadoop.hbase.KeyValue
-
Size of the row length field in bytes
- ROW_OFFSET - Static variable in class org.apache.hadoop.hbase.KeyValue
- ROW_READS_ONLY_ON_MEMSTORE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
- ROW_READS_ONLY_ON_MEMSTORE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
- org.apache.hadoop.hbase.client.RowAccess<T> - Interface in org.apache.hadoop.hbase.client
-
Provide a way to access the inner buffer.
- org.apache.hadoop.hbase.util.RowBloomContext - Class in org.apache.hadoop.hbase.util
-
Handles ROW bloom related context.
- RowBloomContext(BloomFilterWriter, CellComparator) - Constructor for class org.apache.hadoop.hbase.util.RowBloomContext
- org.apache.hadoop.hbase.util.RowBloomHashKey - Class in org.apache.hadoop.hbase.util
- RowBloomHashKey(Cell) - Constructor for class org.apache.hadoop.hbase.util.RowBloomHashKey
- ROWCOL - Enum constant in enum class org.apache.hadoop.hbase.regionserver.BloomType
-
Bloom enabled with Table row & column (family+qualifier) as Key
- org.apache.hadoop.hbase.util.RowColBloomContext - Class in org.apache.hadoop.hbase.util
-
Handles ROWCOL bloom related context.
- RowColBloomContext(BloomFilterWriter, CellComparator) - Constructor for class org.apache.hadoop.hbase.util.RowColBloomContext
- org.apache.hadoop.hbase.util.RowColBloomHashKey - Class in org.apache.hadoop.hbase.util
-
An hash key for ROWCOL bloom.
- RowColBloomHashKey(Cell) - Constructor for class org.apache.hadoop.hbase.util.RowColBloomHashKey
- rowComparator - Variable in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher
-
Row comparator for the region this query is for
- org.apache.hadoop.hbase.mapred.RowCounter - Class in org.apache.hadoop.hbase.mapred
-
A job with a map to count rows.
- org.apache.hadoop.hbase.mapreduce.RowCounter - Class in org.apache.hadoop.hbase.mapreduce
-
A job with a just a map phase to count rows.
- RowCounter() - Constructor for class org.apache.hadoop.hbase.mapred.RowCounter
- RowCounter() - Constructor for class org.apache.hadoop.hbase.mapreduce.RowCounter
- RowEndKeyComparator() - Constructor for class org.apache.hadoop.hbase.util.Bytes.RowEndKeyComparator
- org.apache.hadoop.hbase.filter.RowFilter - Class in org.apache.hadoop.hbase.filter
-
This filter is used to filter based on the key.
- RowFilter(CompareOperator, ByteArrayComparable) - Constructor for class org.apache.hadoop.hbase.filter.RowFilter
-
Constructor.
- org.apache.hadoop.hbase.io.encoding.RowIndexCodecV1 - Class in org.apache.hadoop.hbase.io.encoding
-
Store cells following every row's start offset, so we can binary search to a row's cells.
- RowIndexCodecV1() - Constructor for class org.apache.hadoop.hbase.io.encoding.RowIndexCodecV1
- org.apache.hadoop.hbase.io.encoding.RowIndexEncoderV1 - Class in org.apache.hadoop.hbase.io.encoding
- RowIndexEncoderV1(DataOutputStream, HFileBlockDefaultEncodingContext) - Constructor for class org.apache.hadoop.hbase.io.encoding.RowIndexEncoderV1
- org.apache.hadoop.hbase.io.encoding.RowIndexSeekerV1 - Class in org.apache.hadoop.hbase.io.encoding
- RowIndexSeekerV1(HFileBlockDecodingContext) - Constructor for class org.apache.hadoop.hbase.io.encoding.RowIndexSeekerV1
- rowIsInRange(RegionInfo, byte[]) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Determines if the specified row is within the row range specified by the specified RegionInfo
- rowIsInRange(RegionInfo, byte[], int, short) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
- ROWKEY_COLUMN_SPEC - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
- RowLockImpl(HRegion.RowLockContext, Lock) - Constructor for class org.apache.hadoop.hbase.regionserver.HRegion.RowLockImpl
- org.apache.hadoop.hbase.client.RowMutations - Class in org.apache.hadoop.hbase.client
-
Performs multiple mutations atomically on a single row.
- RowMutations(byte[]) - Constructor for class org.apache.hadoop.hbase.client.RowMutations
- RowMutations(byte[], int) - Constructor for class org.apache.hadoop.hbase.client.RowMutations
-
Create an atomic mutation for the specified row.
- ROWPREFIX_FIXED_LENGTH - Enum constant in enum class org.apache.hadoop.hbase.regionserver.BloomType
-
Bloom enabled with Table row prefix as Key, specify the length of the prefix
- org.apache.hadoop.hbase.util.RowPrefixFixedLengthBloomContext - Class in org.apache.hadoop.hbase.util
-
Handles ROWPREFIX bloom related context.
- RowPrefixFixedLengthBloomContext(BloomFilterWriter, CellComparator, int) - Constructor for class org.apache.hadoop.hbase.util.RowPrefixFixedLengthBloomContext
- RowRange() - Constructor for class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.RowRange
- RowRange(byte[], boolean, byte[], boolean) - Constructor for class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.RowRange
- RowRange(String, boolean, String, boolean) - Constructor for class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.RowRange
-
If the startRow is empty or null, set it to HConstants.EMPTY_BYTE_ARRAY, means begin at the start row of the table.
- org.apache.hadoop.hbase.rest.RowResource - Class in org.apache.hadoop.hbase.rest
- RowResource(TableResource, String, String, String, String, String) - Constructor for class org.apache.hadoop.hbase.rest.RowResource
-
Constructor
- rowResultFromHBase(Result) - Static method in class org.apache.hadoop.hbase.thrift.ThriftUtilities
- rowResultFromHBase(Result[]) - Static method in class org.apache.hadoop.hbase.thrift.ThriftUtilities
-
This utility method creates a list of Thrift TRowResult "struct" based on an array of Hbase RowResult objects.
- rowResultFromHBase(Result[], boolean) - Static method in class org.apache.hadoop.hbase.thrift.ThriftUtilities
-
This utility method creates a list of Thrift TRowResult "struct" based on an Hbase RowResult object.
- org.apache.hadoop.hbase.rest.RowResultGenerator - Class in org.apache.hadoop.hbase.rest
- RowResultGenerator(String, RowSpec, Filter, boolean) - Constructor for class org.apache.hadoop.hbase.rest.RowResultGenerator
- ROWS - Enum constant in enum class org.apache.hadoop.hbase.PerformanceEvaluation.Counter
-
number of rows
- ROWS - Static variable in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.All the row values for the data loaded by
HBaseTestingUtility.loadTable(Table, byte[])
- org.apache.hadoop.hbase.rest.RowSpec - Class in org.apache.hadoop.hbase.rest
-
Parses a path based row/column/timestamp specification into its component elements.
- RowSpec(byte[], byte[], byte[][], long, long, int) - Constructor for class org.apache.hadoop.hbase.rest.RowSpec
- RowSpec(byte[], byte[], Collection<byte[]>, long, long, int) - Constructor for class org.apache.hadoop.hbase.rest.RowSpec
- RowSpec(byte[], byte[], Collection<byte[]>, long, long, int, Collection<String>) - Constructor for class org.apache.hadoop.hbase.rest.RowSpec
- RowSpec(String) - Constructor for class org.apache.hadoop.hbase.rest.RowSpec
- RowSpec(String, String) - Constructor for class org.apache.hadoop.hbase.rest.RowSpec
- ROWSWITHDIFFS - Enum constant in enum class org.apache.hadoop.hbase.mapreduce.SyncTable.SyncMapper.Counter
- org.apache.hadoop.hbase.client.RowTooBigException - Exception in org.apache.hadoop.hbase.client
-
Gets or Scans throw this exception if running without in-row scan flag set and row size appears to exceed max configured size (configurable via hbase.table.max.rowsize).
- org.apache.hadoop.hbase.regionserver.RowTooBigException - Exception in org.apache.hadoop.hbase.regionserver
-
Deprecated.since 0.99.0. Use
RowTooBigException
instead. - RowTooBigException(String) - Constructor for exception org.apache.hadoop.hbase.client.RowTooBigException
- RowTooBigException(String) - Constructor for exception org.apache.hadoop.hbase.regionserver.RowTooBigException
-
Deprecated.
- rowToStr(byte[]) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.NumberStringSplit
- rowToStr(byte[]) - Method in interface org.apache.hadoop.hbase.util.RegionSplitter.SplitAlgorithm
-
byte array representing a row in HBase
- rowToStr(byte[]) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.UniformSplit
- RPAREN - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
ASCII code for RPAREN
- RPC_CODEC_CONF_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
Configuration key for setting RPC codec class name
- RPC_CURRENT_VERSION - Static variable in class org.apache.hadoop.hbase.HConstants
- RPC_FULL_SCAN_REQUEST_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- RPC_FULL_SCAN_REQUEST_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- RPC_GET_REQUEST_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- RPC_GET_REQUEST_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- RPC_HEADER - Static variable in class org.apache.hadoop.hbase.HConstants
-
The first four bytes of Hadoop RPC connections
- RPC_MULTI_REQUEST_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- RPC_MULTI_REQUEST_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- RPC_MUTATE_REQUEST_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- RPC_MUTATE_REQUEST_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- RPC_SCAN_REQUEST_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- RPC_SCAN_REQUEST_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- RPC_THROTTLE_ZNODE - Static variable in class org.apache.hadoop.hbase.quotas.RpcThrottleStorage
- RPC_THROTTLE_ZNODE_DEFAULT - Static variable in class org.apache.hadoop.hbase.quotas.RpcThrottleStorage
- RPC_TIMEOUT_MS - Static variable in class org.apache.hadoop.hbase.regionserver.regionreplication.RegionReplicationSink
- RPC_TIMEOUT_MS_DEFAULT - Static variable in class org.apache.hadoop.hbase.regionserver.regionreplication.RegionReplicationSink
- org.apache.hadoop.hbase.ipc.RpcCall - Interface in org.apache.hadoop.hbase.ipc
-
Interface of all necessary to carry out a RPC method invocation on the server.
- rpcCallback - Variable in class org.apache.hadoop.hbase.ipc.ServerCall
- org.apache.hadoop.hbase.ipc.RpcCallback - Interface in org.apache.hadoop.hbase.ipc
-
Denotes a callback action that has to be executed at the end of an Rpc Call.
- org.apache.hadoop.hbase.ipc.RpcCallContext - Interface in org.apache.hadoop.hbase.ipc
-
Interface of all necessary to carry out a RPC service invocation on the server.
- RpcChannelImplementation(AbstractRpcClient<?>, Address, User, int) - Constructor for class org.apache.hadoop.hbase.ipc.AbstractRpcClient.RpcChannelImplementation
- rpcClient - Variable in class org.apache.hadoop.hbase.client.AsyncConnectionImpl
- rpcClient - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient.RpcChannelImplementation
- org.apache.hadoop.hbase.ipc.RpcClient - Interface in org.apache.hadoop.hbase.ipc
-
Interface for RpcClient implementations so ConnectionManager can handle it.
- org.apache.hadoop.hbase.ipc.RpcClientFactory - Class in org.apache.hadoop.hbase.ipc
-
Factory to create a
RpcClient
- org.apache.hadoop.hbase.ipc.RpcConnectionConstants - Class in org.apache.hadoop.hbase.ipc
-
Constants to be used by RPC connection based utilities.
- org.apache.hadoop.hbase.client.RpcConnectionRegistry - Class in org.apache.hadoop.hbase.client
-
Rpc based connection registry.
- org.apache.hadoop.hbase.client.RpcConnectionRegistryURIFactory - Class in org.apache.hadoop.hbase.client
-
Connection registry creator implementation for creating
RpcConnectionRegistry
. - RpcConnectionRegistryURIFactory() - Constructor for class org.apache.hadoop.hbase.client.RpcConnectionRegistryURIFactory
- org.apache.hadoop.hbase.ipc.RpcControllerFactory - Class in org.apache.hadoop.hbase.ipc
-
Factory to create a
HBaseRpcController
- RpcControllerFactory(Configuration) - Constructor for class org.apache.hadoop.hbase.ipc.RpcControllerFactory
- org.apache.hadoop.hbase.ipc.RpcExecutor - Class in org.apache.hadoop.hbase.ipc
-
Runs the CallRunners passed here via
RpcExecutor.dispatch(CallRunner)
. - RpcExecutor(String, int, int, PriorityFunction, Configuration, Abortable) - Constructor for class org.apache.hadoop.hbase.ipc.RpcExecutor
- RpcExecutor(String, int, String, int, PriorityFunction, Configuration, Abortable) - Constructor for class org.apache.hadoop.hbase.ipc.RpcExecutor
- org.apache.hadoop.hbase.ipc.RpcHandler - Class in org.apache.hadoop.hbase.ipc
-
Thread to handle rpc call.
- org.apache.hadoop.hbase.namequeues.RpcLogDetails - Class in org.apache.hadoop.hbase.namequeues
-
RpcCall details that would be passed on to ring buffer of slow log responses
- RpcLogDetails(RpcCall, Message, String, long, long, long, String, boolean, boolean) - Constructor for class org.apache.hadoop.hbase.namequeues.RpcLogDetails
- org.apache.hadoop.hbase.quotas.RpcQuotaManager - Interface in org.apache.hadoop.hbase.quotas
- org.apache.hadoop.hbase.ipc.RpcScheduler - Class in org.apache.hadoop.hbase.ipc
-
An interface for RPC request scheduling algorithm.
- RpcScheduler() - Constructor for class org.apache.hadoop.hbase.ipc.RpcScheduler
- org.apache.hadoop.hbase.ipc.RpcScheduler.Context - Class in org.apache.hadoop.hbase.ipc
-
Exposes runtime information of a
RpcServer
that aRpcScheduler
may need. - org.apache.hadoop.hbase.regionserver.RpcSchedulerFactory - Interface in org.apache.hadoop.hbase.regionserver
-
A factory class that constructs an
RpcScheduler
. - rpcServer - Variable in class org.apache.hadoop.hbase.HBaseRpcServicesBase
- org.apache.hadoop.hbase.ipc.RpcServer - Class in org.apache.hadoop.hbase.ipc
-
An RPC server that hosts protobuf described Services.
- RpcServer(Server, String, List<RpcServer.BlockingServiceAndInterface>, InetSocketAddress, Configuration, RpcScheduler, boolean) - Constructor for class org.apache.hadoop.hbase.ipc.RpcServer
-
Constructs a server listening on the named port and address.
- org.apache.hadoop.hbase.ipc.RpcServer.BlockingServiceAndInterface - Class in org.apache.hadoop.hbase.ipc
-
Datastructure for passing a
BlockingService
and its associated class of protobuf service interface. - org.apache.hadoop.hbase.ipc.RpcServer.CallCleanup - Interface in org.apache.hadoop.hbase.ipc
- org.apache.hadoop.hbase.ipc.RpcServerFactory - Class in org.apache.hadoop.hbase.ipc
- org.apache.hadoop.hbase.ipc.RpcServerInterface - Interface in org.apache.hadoop.hbase.ipc
- rpcServices - Variable in class org.apache.hadoop.hbase.HBaseServerBase
- rpcServices - Variable in class org.apache.hadoop.hbase.ipc.AnnotationReadingPriorityFunction
- org.apache.hadoop.hbase.quotas.RpcThrottleStorage - Class in org.apache.hadoop.hbase.quotas
-
ZK based rpc throttle storage.
- RpcThrottleStorage(ZKWatcher, Configuration) - Constructor for class org.apache.hadoop.hbase.quotas.RpcThrottleStorage
- rpcThrottlingException() - Method in interface org.apache.hadoop.hbase.metrics.ExceptionTrackingSource
- rpcThrottlingException() - Method in class org.apache.hadoop.hbase.metrics.ExceptionTrackingSourceImpl
- org.apache.hadoop.hbase.quotas.RpcThrottlingException - Exception in org.apache.hadoop.hbase.quotas
-
Describe the throttling result.
- RpcThrottlingException(String) - Constructor for exception org.apache.hadoop.hbase.quotas.RpcThrottlingException
- RpcThrottlingException(RpcThrottlingException.Type, long, String) - Constructor for exception org.apache.hadoop.hbase.quotas.RpcThrottlingException
- org.apache.hadoop.hbase.quotas.RpcThrottlingException.Type - Enum Class in org.apache.hadoop.hbase.quotas
- rpcTimeout - Variable in class org.apache.hadoop.hbase.client.AsyncConnectionImpl
- rpcTimeout - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient.RpcChannelImplementation
- rpcTimeout(int) - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
- RS_COLUMN - Static variable in class org.apache.hadoop.hbase.namequeues.WALEventTrackerTableAccessor
- RS_CONNECT_FAILURE - Enum constant in enum class org.apache.hadoop.hbase.util.HbckErrorReporter.ERROR_CODE
-
Deprecated.
- RS_ENABLE_SERVER_QUERY_METER_METRICS_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
- RS_ENABLE_SERVER_QUERY_METER_METRICS_KEY_DEFAULT - Static variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
- RS_GROUP_ENABLED - Static variable in class org.apache.hadoop.hbase.rsgroup.RSGroupUtil
- RS_HOSTNAME_KEY - Static variable in class org.apache.hadoop.hbase.util.DNS
-
Deprecated.since 2.4.0 and will be removed in 4.0.0. Use
DNS.UNSAFE_RS_HOSTNAME_KEY
instead. - RS_START_TIME_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- RS_START_TIME_NAME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- rsClass(Class<? extends MiniHBaseCluster.MiniHBaseClusterRegionServer>) - Method in class org.apache.hadoop.hbase.StartMiniClusterOption.Builder
-
Deprecated.
- org.apache.hadoop.hbase.regionserver.http.RSDumpServlet - Class in org.apache.hadoop.hbase.regionserver.http
- RSDumpServlet() - Constructor for class org.apache.hadoop.hbase.regionserver.http.RSDumpServlet
- org.apache.hadoop.hbase.rsgroup.RSGroupAdminClient - Class in org.apache.hadoop.hbase.rsgroup
-
Deprecated.Keep it here only for tests, using
Admin
instead. - RSGroupAdminClient(Connection) - Constructor for class org.apache.hadoop.hbase.rsgroup.RSGroupAdminClient
-
Deprecated.
- org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint - Class in org.apache.hadoop.hbase.rsgroup
-
Deprecated.Keep it here only for compatibility with old client, all the logics have been moved into core of HBase.
- RSGroupAdminEndpoint() - Constructor for class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
-
Deprecated.
- org.apache.hadoop.hbase.rsgroup.RSGroupBasedLoadBalancer - Class in org.apache.hadoop.hbase.rsgroup
-
GroupBasedLoadBalancer, used when Region Server Grouping is configured (HBase-6721) It does region balance based on a table's group membership.
- RSGroupBasedLoadBalancer() - Constructor for class org.apache.hadoop.hbase.rsgroup.RSGroupBasedLoadBalancer
-
Used by reflection in
LoadBalancerFactory
. - org.apache.hadoop.hbase.rsgroup.RSGroupInfo - Class in org.apache.hadoop.hbase.rsgroup
-
Stores the group information of region server groups.
- RSGroupInfo(String) - Constructor for class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
- RSGroupInfo(RSGroupInfo) - Constructor for class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
- org.apache.hadoop.hbase.rsgroup.RSGroupInfoManager - Interface in org.apache.hadoop.hbase.rsgroup
-
Interface used to manage RSGroupInfo storage.
- org.apache.hadoop.hbase.rsgroup.RSGroupMajorCompactionTTL - Class in org.apache.hadoop.hbase.rsgroup
-
This script takes an rsgroup as argument and compacts part/all of regions of that table based on the table's TTL.
- org.apache.hadoop.hbase.rsgroup.RSGroupUtil - Class in org.apache.hadoop.hbase.rsgroup
-
Helper class for RSGroup implementation
- org.apache.hadoop.hbase.mob.RSMobFileCleanerChore - Class in org.apache.hadoop.hbase.mob
-
The class RSMobFileCleanerChore for running cleaner regularly to remove the obsolete (files which have no active references to) mob files that were referenced from the current RS.
- RSMobFileCleanerChore() - Constructor for class org.apache.hadoop.hbase.mob.RSMobFileCleanerChore
- RSMobFileCleanerChore(HRegionServer) - Constructor for class org.apache.hadoop.hbase.mob.RSMobFileCleanerChore
- rsPorts(List<Integer>) - Method in class org.apache.hadoop.hbase.StartMiniClusterOption.Builder
-
Deprecated.
- rsPorts(List<Integer>) - Method in class org.apache.hadoop.hbase.testing.TestingHBaseClusterOption.Builder
- org.apache.hadoop.hbase.regionserver.RSRpcServices - Class in org.apache.hadoop.hbase.regionserver
-
Implements the regionserver RPC services.
- RSRpcServices(HRegionServer) - Constructor for class org.apache.hadoop.hbase.regionserver.RSRpcServices
- rsServices - Variable in class org.apache.hadoop.hbase.regionserver.HRegion
- org.apache.hadoop.hbase.regionserver.RSSnapshotVerifier - Class in org.apache.hadoop.hbase.regionserver
-
Used by
SnapshotVerifyProcedure
to verify if the region info and store file info in RegionManifest are intact. - RSSnapshotVerifier(Configuration) - Constructor for class org.apache.hadoop.hbase.regionserver.RSSnapshotVerifier
- org.apache.hadoop.hbase.regionserver.http.RSStatusServlet - Class in org.apache.hadoop.hbase.regionserver.http
- RSStatusServlet() - Constructor for class org.apache.hadoop.hbase.regionserver.http.RSStatusServlet
- rsZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZNodePaths
- run() - Method in class org.apache.hadoop.hbase.chaos.ChaosAgent
- run() - Method in class org.apache.hadoop.hbase.client.locking.EntityLock.LockHeartbeatWorker
- run() - Method in class org.apache.hadoop.hbase.hbtop.screen.Screen
- run() - Method in class org.apache.hadoop.hbase.ipc.CallRunner
- run() - Method in interface org.apache.hadoop.hbase.ipc.RpcCallback
-
Called at the end of an Rpc Call
RpcCallContext
- run() - Method in class org.apache.hadoop.hbase.ipc.RpcHandler
- run() - Method in interface org.apache.hadoop.hbase.ipc.RpcServer.CallCleanup
- run() - Method in class org.apache.hadoop.hbase.JitterScheduledThreadPoolExecutorImpl.JitteredRunnableScheduledFuture
- run() - Method in class org.apache.hadoop.hbase.master.HMaster
- run() - Method in class org.apache.hadoop.hbase.master.HMasterCommandLine.LocalHMaster
- run() - Method in class org.apache.hadoop.hbase.MiniHBaseCluster.MiniHBaseClusterRegionServer
-
Deprecated.
- run() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
The HRegionServer sticks in this loop until closed.
- run() - Method in class org.apache.hadoop.hbase.regionserver.LeaseManager
- run() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl.HRegionMetricsWrapperRunnable
- run() - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImpl.TableMetricsWrapperRunnable
- run() - Method in class org.apache.hadoop.hbase.regionserver.SplitLogWorker
-
Deprecated.
- run() - Method in class org.apache.hadoop.hbase.rest.RESTServer
-
Runs the REST server.
- run() - Method in class org.apache.hadoop.hbase.ScheduledChore
- run() - Method in class org.apache.hadoop.hbase.thrift.CallQueue.Call
- run() - Method in class org.apache.hadoop.hbase.thrift.ThriftServer
-
Run without any command line arguments
- run() - Method in interface org.apache.hadoop.hbase.util.IOExceptionRunnable
- run() - Method in class org.apache.hadoop.hbase.util.MultiThreadedReader.HBaseReaderThread
- run() - Method in class org.apache.hadoop.hbase.util.MultiThreadedUpdater.HBaseUpdaterThread
- run() - Method in class org.apache.hadoop.hbase.util.MultiThreadedWriter.HBaseWriterThread
- run() - Method in class org.apache.hadoop.hbase.wal.AbstractWALRoller
- run(boolean) - Method in interface org.apache.hadoop.hbase.ipc.HBaseRpcController.CancellationCallback
- run(String[]) - Method in class org.apache.hadoop.hbase.backup.BackupDriver
- run(String[]) - Method in interface org.apache.hadoop.hbase.backup.BackupMergeJob
-
Run backup merge operation.
- run(String[]) - Method in class org.apache.hadoop.hbase.backup.RestoreDriver
- run(String[]) - Method in class org.apache.hadoop.hbase.client.example.AsyncClientExample
- run(String[]) - Method in class org.apache.hadoop.hbase.client.example.BufferedMutatorExample
- run(String[]) - Method in class org.apache.hadoop.hbase.client.example.MultiThreadedClientExample
- run(String[]) - Method in class org.apache.hadoop.hbase.client.example.RefreshHFilesClient
- run(String[]) - Method in class org.apache.hadoop.hbase.hbtop.HBTop
- run(String[]) - Method in class org.apache.hadoop.hbase.io.hfile.HFilePrettyPrinter
-
Runs the command-line pretty-printer, and returns the desired command exit code (zero for success, non-zero for failure).
- run(String[]) - Method in class org.apache.hadoop.hbase.mapred.RowCounter
- run(String[]) - Method in class org.apache.hadoop.hbase.mapreduce.CellCounter
- run(String[]) - Method in class org.apache.hadoop.hbase.mapreduce.CopyTable
- run(String[]) - Method in class org.apache.hadoop.hbase.mapreduce.Export
- run(String[]) - Method in class org.apache.hadoop.hbase.mapreduce.HashTable
- run(String[]) - Method in class org.apache.hadoop.hbase.mapreduce.Import
- run(String[]) - Method in class org.apache.hadoop.hbase.mapreduce.ImportTsv
- run(String[]) - Method in class org.apache.hadoop.hbase.mapreduce.IndexBuilder
- run(String[]) - Method in class org.apache.hadoop.hbase.mapreduce.SampleUploader
-
Main entry point.
- run(String[]) - Method in class org.apache.hadoop.hbase.mapreduce.SyncTable
- run(String[]) - Method in class org.apache.hadoop.hbase.mapreduce.WALPlayer
- run(String[]) - Method in class org.apache.hadoop.hbase.master.HMasterCommandLine
- run(String[]) - Method in class org.apache.hadoop.hbase.mob.ExpiredMobFileCleaner
- run(String[]) - Method in class org.apache.hadoop.hbase.mob.mapreduce.MobRefReporter
-
Main method for the tool.
- run(String[]) - Method in class org.apache.hadoop.hbase.PerformanceEvaluation
- run(String[]) - Method in class org.apache.hadoop.hbase.regionserver.CompactionTool
- run(String[]) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServerCommandLine
- run(String[]) - Method in class org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileListFilePrettyPrinter
- run(String[]) - Method in class org.apache.hadoop.hbase.replication.CopyReplicationPeers
- run(String[]) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupMajorCompactionTTL
- run(String[]) - Method in class org.apache.hadoop.hbase.thrift.ThriftServer
- run(String[]) - Method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
- run(String[]) - Method in class org.apache.hadoop.hbase.util.compaction.MajorCompactor
- run(String[]) - Method in class org.apache.hadoop.hbase.util.compaction.MajorCompactorTTL
- run(String[]) - Method in class org.apache.hadoop.hbase.util.MapreduceDependencyClasspathTool
- run(String[]) - Method in class org.apache.hadoop.hbase.wal.WALPerformanceEvaluation
- run(String[]) - Static method in class org.apache.hadoop.hbase.wal.WALPrettyPrinter
-
Pass one or more log file names and formatting options and it will dump out a text version of the contents on
stdout
. - run(String[]) - Method in class org.apache.hadoop.hbase.zookeeper.ZKAclReset
- run(Path[], TableName[], Path, TableName[], boolean) - Method in interface org.apache.hadoop.hbase.backup.RestoreJob
-
Run restore operation
- run(Mapper.Context) - Method in class org.apache.hadoop.hbase.mapreduce.MultithreadedTableMapper
-
Run the application's maps using a thread pool.
- run(R) - Method in class org.apache.hadoop.hbase.ipc.BlockingRpcCallback
-
Called on completion of the RPC call with the response object, or
null
in the case of an error. - run(R) - Method in class org.apache.hadoop.hbase.ipc.CoprocessorRpcUtils.BlockingRpcCallback
-
Called on completion of the RPC call with the response object, or
null
in the case of an error. - RUN_SHUTDOWN_HOOK - Static variable in class org.apache.hadoop.hbase.regionserver.ShutdownHook
-
Key for boolean configuration whose default is true.
- runAs(PrivilegedAction<T>) - Method in class org.apache.hadoop.hbase.security.User
-
Executes the given action within the context of this user.
- runAs(PrivilegedAction<T>) - Method in class org.apache.hadoop.hbase.security.User.SecureHadoopUser
- runAs(PrivilegedExceptionAction<T>) - Method in class org.apache.hadoop.hbase.security.User
-
Executes the given action within the context of this user.
- runAs(PrivilegedExceptionAction<T>) - Method in class org.apache.hadoop.hbase.security.User.SecureHadoopUser
- runAsLoginUser(PrivilegedExceptionAction<T>) - Static method in class org.apache.hadoop.hbase.security.User
-
Executes the given action as the login user
- runBenchmark(HFilePerformanceEvaluation.RowOrientedBenchmark, int, String, String) - Method in class org.apache.hadoop.hbase.HFilePerformanceEvaluation
- runCatalogJanitor() - Method in interface org.apache.hadoop.hbase.client.Admin
-
Ask for a scan of the catalog table.
- runCatalogJanitor() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Ask for a scan of the catalog table.
- runCatalogScan(RpcController, MasterProtos.RunCatalogScanRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- runCleanerChore() - Method in interface org.apache.hadoop.hbase.client.Admin
-
Ask for cleaner chore to run.
- runCleanerChore() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Ask for cleaner chore to run.
- runCleanerChore(RpcController, MasterProtos.RunCleanerChoreRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- runCmdAsync(List<String>) - Static method in class org.apache.hadoop.hbase.util.ProcessUtils
- runHbckChore() - Method in class org.apache.hadoop.hbase.client.HBaseHbck
- runHbckChore() - Method in interface org.apache.hadoop.hbase.client.Hbck
-
Request HBCK chore to run at master side.
- runHbckChore(RpcController, MasterProtos.RunHbckChoreRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- RunnerStats(MetricRegistry) - Constructor for class org.apache.hadoop.hbase.client.MetricsConnection.RunnerStats
- RUNNING - Enum constant in enum class org.apache.hadoop.hbase.backup.BackupInfo.BackupState
- RUNNING - Enum constant in enum class org.apache.hadoop.hbase.io.FileChangeWatcher.State
- RUNNING - Enum constant in enum class org.apache.hadoop.hbase.ServerTask.State
- runReplicationBarrierCleaner() - Method in class org.apache.hadoop.hbase.master.HMaster
- runReplicationBarrierCleaner() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Run the ReplicationBarrierChore.
- RunResult(long, long, long, Histogram) - Constructor for class org.apache.hadoop.hbase.PerformanceEvaluation.RunResult
- RunResult(long, Histogram) - Constructor for class org.apache.hadoop.hbase.PerformanceEvaluation.RunResult
- org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor - Class in org.apache.hadoop.hbase.ipc
-
RPC Executor that uses different queues for reads and writes.
- RWQueueRpcExecutor(String, int, int, PriorityFunction, Configuration, Abortable) - Constructor for class org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
S
- S - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
ASCII code for 'S'
- safeClose(ChannelOutboundInvoker) - Static method in class org.apache.hadoop.hbase.util.NettyFutureUtils
-
Close the channel and eat the returned future by logging the error when the future is completed with error.
- safeGetAsStr(List<T>, int) - Static method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- safeGetHeapMemoryUsage() - Static method in class org.apache.hadoop.hbase.io.util.MemorySizeUtil
-
Return JVM memory statistics while properly handling runtime exceptions from the JVM.
- safeWrite(ChannelOutboundInvoker, Object) - Static method in class org.apache.hadoop.hbase.util.NettyFutureUtils
-
Call write on the channel and eat the returned future by logging the error when the future is completed with error.
- safeWriteAndFlush(ChannelOutboundInvoker, Object) - Static method in class org.apache.hadoop.hbase.util.NettyFutureUtils
-
Call writeAndFlush on the channel and eat the returned future by logging the error when the future is completed with error.
- org.apache.hadoop.hbase.mapreduce.SampleUploader - Class in org.apache.hadoop.hbase.mapreduce
-
Sample Uploader MapReduce
- SampleUploader() - Constructor for class org.apache.hadoop.hbase.mapreduce.SampleUploader
- SANITY_CHECK_FAILURE - Enum constant in enum class org.apache.hadoop.hbase.HConstants.OperationStatusCode
- sanityCheck(Configuration, TableDescriptor) - Static method in class org.apache.hadoop.hbase.util.TableDescriptorChecker
-
Checks whether the table conforms to some sane limits, and configured values (compression, etc) work.
- sanityCheckLeft(byte[], Cell) - Method in class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter
-
Subclasses can call this method to make sure the first KV is within multi-writer range.
- sanityCheckRight(byte[], Cell) - Method in class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter
-
Subclasses can call this method to make sure the last KV is within multi-writer range.
- SASL_DEFAULT_REALM - Static variable in class org.apache.hadoop.hbase.security.SaslUtil
- org.apache.hadoop.hbase.security.SaslChallengeDecoder - Class in org.apache.hadoop.hbase.security
-
Decode the sasl challenge sent by RpcServer.
- SaslChallengeDecoder() - Constructor for class org.apache.hadoop.hbase.security.SaslChallengeDecoder
- saslClient - Variable in class org.apache.hadoop.hbase.security.AbstractHBaseSaslRpcClient
- saslConnect(InputStream, OutputStream) - Method in class org.apache.hadoop.hbase.security.HBaseSaslRpcClient
-
Do client side SASL authentication with server via the given InputStream and OutputStream
- saslProps - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
- saslProps - Variable in class org.apache.hadoop.hbase.security.AbstractHBaseSaslRpcClient
- org.apache.hadoop.hbase.security.SaslStatus - Enum Class in org.apache.hadoop.hbase.security
- org.apache.hadoop.hbase.security.SaslUnwrapHandler - Class in org.apache.hadoop.hbase.security
-
Unwrap sasl messages.
- SaslUnwrapHandler(SaslUnwrapHandler.Unwrapper) - Constructor for class org.apache.hadoop.hbase.security.SaslUnwrapHandler
- org.apache.hadoop.hbase.security.SaslUnwrapHandler.Unwrapper - Interface in org.apache.hadoop.hbase.security
- org.apache.hadoop.hbase.security.SaslUtil - Class in org.apache.hadoop.hbase.security
- SaslUtil() - Constructor for class org.apache.hadoop.hbase.security.SaslUtil
- org.apache.hadoop.hbase.security.SaslUtil.QualityOfProtection - Enum Class in org.apache.hadoop.hbase.security
- org.apache.hadoop.hbase.security.SaslWrapHandler - Class in org.apache.hadoop.hbase.security
-
wrap sasl messages.
- SaslWrapHandler(SaslWrapHandler.Wrapper) - Constructor for class org.apache.hadoop.hbase.security.SaslWrapHandler
- org.apache.hadoop.hbase.security.SaslWrapHandler.Wrapper - Interface in org.apache.hadoop.hbase.security
- save() - Static method in class org.apache.hadoop.hbase.io.hfile.CacheableDeserializerIdManager
-
Snapshot a map of the current identifiers to class names for reconstruction on reading out of a file.
- saveMetadata(HFile.Writer) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoder
-
Save metadata in HFile which will be written to disk
- saveMetadata(HFile.Writer) - Method in class org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoderImpl
- saveMetadata(HFile.Writer) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileIndexBlockEncoder
-
Save metadata in HFile which will be written to disk
- saveMetadata(HFile.Writer) - Method in class org.apache.hadoop.hbase.io.hfile.HFileIndexBlockEncoderImpl
- saveMetadata(HFile.Writer) - Method in class org.apache.hadoop.hbase.io.hfile.NoOpDataBlockEncoder
- saveMetadata(HFile.Writer) - Method in class org.apache.hadoop.hbase.io.hfile.NoOpIndexBlockEncoder
- scan(Scan, C) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
The scan API uses the observer pattern.
- scan(RpcController, ClientProtos.ScanRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
Scan data in a table.
- org.apache.hadoop.hbase.client.Scan - Class in org.apache.hadoop.hbase.client
-
Used to perform Scan operations.
- Scan() - Constructor for class org.apache.hadoop.hbase.client.Scan
-
Create a Scan operation across all rows.
- Scan(Get) - Constructor for class org.apache.hadoop.hbase.client.Scan
-
Builds a scan object with the same specs as get.
- Scan(Scan) - Constructor for class org.apache.hadoop.hbase.client.Scan
-
Creates a new instance of this class while copying all values.
- SCAN - Enum constant in enum class org.apache.hadoop.hbase.quotas.OperationQuota.OperationType
- SCAN - Enum constant in enum class org.apache.hadoop.hbase.regionserver.Region.Operation
- SCAN - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
Base-64 encoded scanner.
- SCAN_ATTRIBUTES_TABLE_NAME - Static variable in class org.apache.hadoop.hbase.client.Scan
- SCAN_BATCH_SIZE - Static variable in interface org.apache.hadoop.hbase.rest.Constants
- SCAN_BATCHSIZE - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
Set the maximum number of values to return for each call to next().
- SCAN_BLOCK_BYTES_SCANNED_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- SCAN_CACHE_BLOCKS - Static variable in interface org.apache.hadoop.hbase.rest.Constants
- SCAN_CACHEBLOCKS - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
Set to false to disable server-side caching of blocks for this scan.
- SCAN_CACHEDROWS - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
The number of rows for caching that will be passed to scanners.
- SCAN_COLUMN - Static variable in interface org.apache.hadoop.hbase.rest.Constants
- SCAN_COLUMN_FAMILY - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
Column Family to Scan
- SCAN_COLUMNS - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
Space delimited list of columns and column families to scan.
- SCAN_END_ROW - Static variable in interface org.apache.hadoop.hbase.rest.Constants
- SCAN_END_TIME - Static variable in interface org.apache.hadoop.hbase.rest.Constants
- SCAN_FETCH_SIZE - Static variable in interface org.apache.hadoop.hbase.rest.Constants
- SCAN_FILTER - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
Deprecated.Since 2.4.18/2.5.9/2.6.0, will be removed in 4.0.0. Please use
Constants.FILTER
instead. - SCAN_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- SCAN_LIMIT - Static variable in interface org.apache.hadoop.hbase.rest.Constants
- SCAN_MAX_VERSIONS - Static variable in interface org.apache.hadoop.hbase.rest.Constants
- SCAN_MAXVERSIONS - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
The maximum number of version to return.
- SCAN_QUEUE_DESC - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
- SCAN_QUEUE_NAME - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
- SCAN_REVERSED - Static variable in interface org.apache.hadoop.hbase.rest.Constants
- SCAN_ROW_START - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
Scan start row
- SCAN_ROW_STOP - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
Scan stop row
- SCAN_SIZE_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- SCAN_START_ROW - Static variable in interface org.apache.hadoop.hbase.rest.Constants
- SCAN_START_TIME - Static variable in interface org.apache.hadoop.hbase.rest.Constants
- SCAN_TIME_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- SCAN_TIMERANGE_END - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
The ending timestamp used to filter columns with a specific range of versions.
- SCAN_TIMERANGE_START - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
The starting timestamp used to filter columns with a specific range of versions.
- SCAN_TIMESTAMP - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
The timestamp used to filter columns with a specific timestamp.
- org.apache.hadoop.hbase.client.Scan.ReadType - Enum Class in org.apache.hadoop.hbase.client
- scanAll(Scan) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
Return all the results that match the given scan object.
- scanByRegionEncodedName(Connection, String) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Scans META table for a row whose key contains the specified regionEncodedName, returning a single related
Result
instance if any row is found, null otherwise. - org.apache.hadoop.hbase.regionserver.querymatcher.ScanDeleteTracker - Class in org.apache.hadoop.hbase.regionserver.querymatcher
-
This class is responsible for the tracking and enforcement of Deletes during the course of a Scan operation.
- ScanDeleteTracker(CellComparator) - Constructor for class org.apache.hadoop.hbase.regionserver.querymatcher.ScanDeleteTracker
- org.apache.hadoop.hbase.regionserver.ScanInfo - Class in org.apache.hadoop.hbase.regionserver
-
Immutable information for scans over a store.
- ScanInfo(Configuration, byte[], int, int, long, KeepDeletedCells, long, long, CellComparator, boolean) - Constructor for class org.apache.hadoop.hbase.regionserver.ScanInfo
- ScanInfo(Configuration, ColumnFamilyDescriptor, long, long, CellComparator) - Constructor for class org.apache.hadoop.hbase.regionserver.ScanInfo
- scanMeta(Connection, byte[], byte[], ClientMetaTableAccessor.QueryType, int, ClientMetaTableAccessor.Visitor) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Performs a scan of META table.
- scanMeta(Connection, byte[], byte[], ClientMetaTableAccessor.QueryType, ClientMetaTableAccessor.Visitor) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
- scanMeta(Connection, byte[], byte[], ClientMetaTableAccessor.QueryType, Filter, int, ClientMetaTableAccessor.Visitor) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
- scanMeta(Connection, ClientMetaTableAccessor.Visitor, TableName, byte[], int) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Performs a scan of META table for given table starting from given row.
- scanMetaForTableRegions(Connection, ClientMetaTableAccessor.Visitor, TableName) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
- scanMetrics - Variable in class org.apache.hadoop.hbase.client.AbstractClientScanner
- SCANNER_LEASE_EXPIRED_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- SCANNER_LEASE_EXPIRED_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- scannerClose(int) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
- scannerContext - Variable in class org.apache.hadoop.hbase.regionserver.MemStoreSegmentsIterator
- org.apache.hadoop.hbase.regionserver.ScannerContext - Class in org.apache.hadoop.hbase.regionserver
-
ScannerContext instances encapsulate limit tracking AND progress towards those limits during invocations of
InternalScanner.next(java.util.List)
andInternalScanner.next(java.util.List)
. - org.apache.hadoop.hbase.regionserver.ScannerContext.Builder - Class in org.apache.hadoop.hbase.regionserver
- org.apache.hadoop.hbase.regionserver.ScannerContext.LimitScope - Enum Class in org.apache.hadoop.hbase.regionserver
-
The various scopes where a limit can be enforced.
- org.apache.hadoop.hbase.regionserver.ScannerContext.NextState - Enum Class in org.apache.hadoop.hbase.regionserver
-
The possible states a scanner may be in following a call to
InternalScanner.next(List)
- scannerGet(int) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
- scannerGetList(int, int) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
- org.apache.hadoop.hbase.regionserver.ScannerIdGenerator - Class in org.apache.hadoop.hbase.regionserver
-
Generate a new style scanner id to prevent collision with previous started server or other RSs.
- ScannerIdGenerator(ServerName) - Constructor for class org.apache.hadoop.hbase.regionserver.ScannerIdGenerator
- org.apache.hadoop.hbase.rest.ScannerInstanceResource - Class in org.apache.hadoop.hbase.rest
- ScannerInstanceResource() - Constructor for class org.apache.hadoop.hbase.rest.ScannerInstanceResource
- ScannerInstanceResource(String, String, ResultGenerator, int) - Constructor for class org.apache.hadoop.hbase.rest.ScannerInstanceResource
- scannerOpen(ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
- scannerOpenTs(ByteBuffer, ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
- scannerOpenWithPrefix(ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
- scannerOpenWithScan(ByteBuffer, TScan, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
- scannerOpenWithStop(ByteBuffer, ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
- scannerOpenWithStopTs(ByteBuffer, ByteBuffer, ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
- scannerResetException() - Method in interface org.apache.hadoop.hbase.metrics.ExceptionTrackingSource
- scannerResetException() - Method in class org.apache.hadoop.hbase.metrics.ExceptionTrackingSourceImpl
- org.apache.hadoop.hbase.exceptions.ScannerResetException - Exception in org.apache.hadoop.hbase.exceptions
-
Thrown when the server side has received an Exception, and asks the Client to reset the scanner state by closing the current region scanner, and reopening from the start of last seen row.
- ScannerResetException() - Constructor for exception org.apache.hadoop.hbase.exceptions.ScannerResetException
-
constructor
- ScannerResetException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.ScannerResetException
-
Constructor
- ScannerResetException(String, Exception) - Constructor for exception org.apache.hadoop.hbase.exceptions.ScannerResetException
- org.apache.hadoop.hbase.rest.ScannerResource - Class in org.apache.hadoop.hbase.rest
- ScannerResource(TableResource) - Constructor for class org.apache.hadoop.hbase.rest.ScannerResource
-
Constructor
- org.apache.hadoop.hbase.rest.ScannerResultGenerator - Class in org.apache.hadoop.hbase.rest
- ScannerResultGenerator(String, RowSpec, Filter, boolean) - Constructor for class org.apache.hadoop.hbase.rest.ScannerResultGenerator
- ScannerResultGenerator(String, RowSpec, Filter, int, boolean) - Constructor for class org.apache.hadoop.hbase.rest.ScannerResultGenerator
- ScannerResultGenerator(String, RowSpec, Filter, int, boolean, int) - Constructor for class org.apache.hadoop.hbase.rest.ScannerResultGenerator
- scannersForDelayedClose - Variable in class org.apache.hadoop.hbase.regionserver.KeyValueHeap
- org.apache.hadoop.hbase.regionserver.ScanOptions - Interface in org.apache.hadoop.hbase.regionserver
-
This class gives you the ability to change the max versions and TTL options before opening a scanner for a Store.
- org.apache.hadoop.hbase.ScanPerformanceEvaluation - Class in org.apache.hadoop.hbase
-
A simple performance evaluation tool for single client and MR scans and snapshot scans.
- ScanPerformanceEvaluation() - Constructor for class org.apache.hadoop.hbase.ScanPerformanceEvaluation
- org.apache.hadoop.hbase.ScanPerformanceEvaluation.MyMapper<KEYOUT,
VALUEOUT> - Class in org.apache.hadoop.hbase - org.apache.hadoop.hbase.ScanPerformanceEvaluation.ScanCounter - Enum Class in org.apache.hadoop.hbase
- org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher - Class in org.apache.hadoop.hbase.regionserver.querymatcher
-
A query matcher that is specifically designed for the scan case.
- ScanQueryMatcher(ExtendedCell, ScanInfo, ColumnTracker, long, long) - Constructor for class org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher
- org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher.MatchCode - Enum Class in org.apache.hadoop.hbase.regionserver.querymatcher
-
ScanQueryMatcher.match(org.apache.hadoop.hbase.ExtendedCell)
return codes. - org.apache.hadoop.hbase.client.ScanResultConsumer - Interface in org.apache.hadoop.hbase.client
-
Receives
Result
for an asynchronous scan. - org.apache.hadoop.hbase.client.ScanResultConsumerBase - Interface in org.apache.hadoop.hbase.client
-
The base interface for scan result consumer.
- SCANS - Static variable in class org.apache.hadoop.hbase.mapreduce.MultiTableInputFormat
-
Job parameter that specifies the scan list.
- org.apache.hadoop.hbase.regionserver.ScanType - Enum Class in org.apache.hadoop.hbase.regionserver
-
Enum to distinguish general scan types.
- org.apache.hadoop.hbase.regionserver.querymatcher.ScanWildcardColumnTracker - Class in org.apache.hadoop.hbase.regionserver.querymatcher
-
Keeps track of the columns for a scan if they are not explicitly specified
- ScanWildcardColumnTracker(int, int, long, CellComparator) - Constructor for class org.apache.hadoop.hbase.regionserver.querymatcher.ScanWildcardColumnTracker
-
Return maxVersions of every row.
- scheduleChore(ScheduledChore) - Method in class org.apache.hadoop.hbase.ChoreService
-
Schedule a chore.
- org.apache.hadoop.hbase.ScheduledChore - Class in org.apache.hadoop.hbase
-
ScheduledChore is a task performed on a period in hbase.
- ScheduledChore() - Constructor for class org.apache.hadoop.hbase.ScheduledChore
-
Construct a ScheduledChore
- ScheduledChore(String, Stoppable, int) - Constructor for class org.apache.hadoop.hbase.ScheduledChore
-
Construct a ScheduledChore
- ScheduledChore(String, Stoppable, int, long) - Constructor for class org.apache.hadoop.hbase.ScheduledChore
-
Construct a ScheduledChore
- ScheduledChore(String, Stoppable, int, long, TimeUnit) - Constructor for class org.apache.hadoop.hbase.ScheduledChore
-
Construct a ScheduledChore
- scheduleFlush(String, List<byte[]>) - Method in class org.apache.hadoop.hbase.regionserver.LogRoller
- scheduleFlush(String, List<byte[]>) - Method in class org.apache.hadoop.hbase.wal.AbstractWALRoller
- scheduler - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
- scheduleSCPsForUnknownServers() - Method in class org.apache.hadoop.hbase.client.HBaseHbck
- scheduleSCPsForUnknownServers() - Method in interface org.apache.hadoop.hbase.client.Hbck
- scheduleSCPsForUnknownServers(RpcController, MasterProtos.ScheduleSCPsForUnknownServersRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- scheduleServerCrashProcedure(RpcController, MasterProtos.ScheduleServerCrashProcedureRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- scheduleServerCrashProcedures(List<ServerName>) - Method in class org.apache.hadoop.hbase.client.HBaseHbck
- scheduleServerCrashProcedures(List<ServerName>) - Method in interface org.apache.hadoop.hbase.client.Hbck
- org.apache.hadoop.hbase.rest.SchemaResource - Class in org.apache.hadoop.hbase.rest
- SchemaResource(TableResource) - Constructor for class org.apache.hadoop.hbase.rest.SchemaResource
-
Constructor
- org.apache.hadoop.hbase.replication.ScopeWALEntryFilter - Class in org.apache.hadoop.hbase.replication
-
Keeps KVs that are scoped other than local
- ScopeWALEntryFilter() - Constructor for class org.apache.hadoop.hbase.replication.ScopeWALEntryFilter
- org.apache.hadoop.hbase.hbtop.screen.Screen - Class in org.apache.hadoop.hbase.hbtop.screen
-
This dispatches key presses and timers to the current
ScreenView
. - Screen(Configuration, long, Mode, List<Field>, Field, Boolean, List<RecordFilter>, long, boolean) - Constructor for class org.apache.hadoop.hbase.hbtop.screen.Screen
- org.apache.hadoop.hbase.hbtop.terminal.impl.ScreenBuffer - Class in org.apache.hadoop.hbase.hbtop.terminal.impl
-
Represents a buffer of the terminal screen for double-buffering.
- ScreenBuffer() - Constructor for class org.apache.hadoop.hbase.hbtop.terminal.impl.ScreenBuffer
- org.apache.hadoop.hbase.hbtop.screen.ScreenView - Interface in org.apache.hadoop.hbase.hbtop.screen
-
An interface for a screen view that handles key presses and timers.
- searchDelimiterIndex(byte[], int, int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Find index of passed delimiter.
- searchDelimiterIndex(ByteBuffer, int, int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Find index of passed delimiter.
- searchDelimiterIndexInReverse(byte[], int, int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Find index of passed delimiter walking from end of buffer backwards.
- searchDelimiterIndexInReverse(ByteBuffer, int, int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Find index of passed delimiter walking from end of buffer backwards.
- searchTreeLevel - Variable in class org.apache.hadoop.hbase.io.hfile.NoOpIndexBlockEncoder.NoOpEncodedSeeker
- second - Variable in class org.apache.hadoop.hbase.util.Pair
- SECONDARY - Enum constant in enum class org.apache.hadoop.hbase.favored.FavoredNodesPlan.Position
- secretManager - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
- SECURE_AUTHENTICATION - Enum constant in enum class org.apache.hadoop.hbase.client.security.SecurityCapability
- secureBulkLoadHFiles(HRegion, ClientProtos.BulkLoadHFileRequest) - Method in class org.apache.hadoop.hbase.regionserver.SecureBulkLoadManager
- secureBulkLoadHFiles(HRegion, ClientProtos.BulkLoadHFileRequest, List<String>) - Method in class org.apache.hadoop.hbase.regionserver.SecureBulkLoadManager
- org.apache.hadoop.hbase.regionserver.SecureBulkLoadManager - Class in org.apache.hadoop.hbase.regionserver
-
Bulk loads in secure mode.
- SecureHadoopUser() - Constructor for class org.apache.hadoop.hbase.security.User.SecureHadoopUser
- SecureHadoopUser(UserGroupInformation) - Constructor for class org.apache.hadoop.hbase.security.User.SecureHadoopUser
- SecureHadoopUser(UserGroupInformation, LoadingCache<String, String[]>) - Constructor for class org.apache.hadoop.hbase.security.User.SecureHadoopUser
- secureRandom(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Fill given array with random bytes using a strong random number generator.
- secureRandom(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Fill given array with random bytes at the specified position using a strong random number generator.
- org.apache.hadoop.hbase.regionserver.wal.SecureWALCellCodec - Class in org.apache.hadoop.hbase.regionserver.wal
-
A WALCellCodec that encrypts the WALedits.
- SecureWALCellCodec(Configuration, Decryptor) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.SecureWALCellCodec
- SecureWALCellCodec(Configuration, Encryptor) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.SecureWALCellCodec
- SecureWALCellCodec(Configuration, CompressionContext) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.SecureWALCellCodec
- SECURITY_PREAMBLE_HEADER - Static variable in interface org.apache.hadoop.hbase.ipc.RpcClient
- org.apache.hadoop.hbase.client.security.SecurityCapability - Enum Class in org.apache.hadoop.hbase.client.security
-
Available security capabilities
- org.apache.hadoop.hbase.security.SecurityConstants - Class in org.apache.hadoop.hbase.security
-
SecurityConstants holds a bunch of kerberos-related constants
- securityEnabled - Variable in class org.apache.hadoop.hbase.thrift.ThriftServer
- org.apache.hadoop.hbase.http.SecurityHeadersFilter - Class in org.apache.hadoop.hbase.http
- SecurityHeadersFilter() - Constructor for class org.apache.hadoop.hbase.http.SecurityHeadersFilter
- org.apache.hadoop.hbase.security.SecurityInfo - Class in org.apache.hadoop.hbase.security
-
Maps RPC protocol interfaces to required configuration
- SecurityInfo(String, AuthenticationProtos.TokenIdentifier.Kind) - Constructor for class org.apache.hadoop.hbase.security.SecurityInfo
- SecurityInfo(AuthenticationProtos.TokenIdentifier.Kind, String...) - Constructor for class org.apache.hadoop.hbase.security.SecurityInfo
- org.apache.hadoop.hbase.ipc.SecurityNotEnabledException - Exception in org.apache.hadoop.hbase.ipc
-
Will be thrown when server received a security preamble call for asking the server principal but security is not enabled for this server.
- SecurityNotEnabledException() - Constructor for exception org.apache.hadoop.hbase.ipc.SecurityNotEnabledException
- org.apache.hadoop.hbase.security.SecurityUtil - Class in org.apache.hadoop.hbase.security
-
Security related generic utility methods.
- SecurityUtil() - Constructor for class org.apache.hadoop.hbase.security.SecurityUtil
- seek(long) - Method in class org.apache.hadoop.hbase.io.FileLink.FileLinkInputStream
- seek(ExtendedCell) - Method in class org.apache.hadoop.hbase.regionserver.KeyValueHeap
-
Seeks all scanners at or below the specified seek key.
- seek(ExtendedCell) - Method in interface org.apache.hadoop.hbase.regionserver.KeyValueScanner
-
Seek the scanner at or after the specified KeyValue.
- seek(ExtendedCell) - Method in class org.apache.hadoop.hbase.regionserver.ReversedKeyValueHeap
- seek(ExtendedCell) - Method in class org.apache.hadoop.hbase.regionserver.ReversedStoreScanner
- seek(ExtendedCell) - Method in class org.apache.hadoop.hbase.regionserver.SegmentScanner
-
Seek the scanner at or after the specified Cell.
- seek(ExtendedCell) - Method in class org.apache.hadoop.hbase.regionserver.SnapshotSegmentScanner
- seek(ExtendedCell) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
- seek(ExtendedCell) - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
- seek(ExtendedCell) - Method in class org.apache.hadoop.hbase.util.CollectionBackedScanner
- SEEK_NEXT_COL - Enum constant in enum class org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher.MatchCode
-
Done with column, seek to next.
- SEEK_NEXT_ROW - Enum constant in enum class org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher.MatchCode
-
Done with the row, seek there.
- SEEK_NEXT_USING_HINT - Enum constant in enum class org.apache.hadoop.hbase.filter.Filter.ReturnCode
-
Seek to next key which is given as hint by the filter.
- SEEK_NEXT_USING_HINT - Enum constant in enum class org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher.MatchCode
-
Seek to next key which is given as hint.
- seekAsDirection(ExtendedCell) - Method in class org.apache.hadoop.hbase.regionserver.ReversedStoreScanner
-
Do a backwardSeek in a reversed StoreScanner(scan backward)
- seekAsDirection(ExtendedCell) - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
Do a reseek in a normal StoreScanner(scan forward)
- seekAtOrAfter(HFileScanner, ExtendedCell) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
-
Returns false if not found or if k is after the end.
- seekBefore(ExtendedCell) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
- seekBefore(ExtendedCell) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
-
Consider the cell stream of all the cells in the file,
c[0] ..
- seekFirst(TNode) - Method in class org.apache.hadoop.hbase.util.AvlUtil.AvlTreeIterator
-
Reset the iterator, and seeks to the first (min) node of the tree
- seekScanners(List<? extends KeyValueScanner>, ExtendedCell, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.ReversedStoreScanner
- seekScanners(List<? extends KeyValueScanner>, ExtendedCell, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
Seek the specified scanners with the given key
- seekTo() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
-
Positions this scanner at the start of the file.
- seekTo() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
-
Positions this scanner at the start of the file.
- seekTo(ExtendedCell) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
- seekTo(ExtendedCell) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
-
SeekTo or just before the passed
cell
. - seekTo(ExtendedCell, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
-
An internal API function.
- seekTo(TNode, Object, AvlUtil.AvlKeyComparator<TNode>) - Method in class org.apache.hadoop.hbase.util.AvlUtil.AvlTreeIterator
-
Reset the iterator, and seeks to the specified key
- seekToKeyInBlock(ExtendedCell, boolean) - Method in interface org.apache.hadoop.hbase.io.encoding.DataBlockEncoder.EncodedSeeker
-
Moves the seeker position within the current block to: the last key that that is less than or equal to the given key if
seekBefore
is false the last key that is strictly less than the given key ifseekBefore
is true. - seekToKeyInBlock(ExtendedCell, boolean) - Method in class org.apache.hadoop.hbase.io.encoding.RowIndexSeekerV1
- seekToLastRow() - Method in interface org.apache.hadoop.hbase.regionserver.KeyValueScanner
-
Seek the scanner at the first KeyValue of last row
- seekToLastRow() - Method in class org.apache.hadoop.hbase.regionserver.NonReversedNonLazyKeyValueScanner
- seekToLastRow() - Method in class org.apache.hadoop.hbase.regionserver.ReversedKeyValueHeap
- seekToLastRow() - Method in class org.apache.hadoop.hbase.regionserver.SegmentScanner
-
Seek the scanner at the first KeyValue of last row
- seekToLastRow() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
- seekToNewSource(long) - Method in class org.apache.hadoop.hbase.io.FileLink.FileLinkInputStream
- seekToNextRow(ExtendedCell) - Method in class org.apache.hadoop.hbase.regionserver.ReversedStoreScanner
- seekToNextRow(ExtendedCell) - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
- seekToPreviousRow(ExtendedCell) - Method in interface org.apache.hadoop.hbase.regionserver.KeyValueScanner
-
Seek the scanner at the first Cell of the row which is the previous row of specified key
- seekToPreviousRow(ExtendedCell) - Method in class org.apache.hadoop.hbase.regionserver.NonReversedNonLazyKeyValueScanner
- seekToPreviousRow(ExtendedCell) - Method in class org.apache.hadoop.hbase.regionserver.ReversedKeyValueHeap
- seekToPreviousRow(ExtendedCell) - Method in class org.apache.hadoop.hbase.regionserver.ReversedStoreScanner
- seekToPreviousRow(ExtendedCell) - Method in class org.apache.hadoop.hbase.regionserver.SegmentScanner
-
Seek the scanner at the first Cell of the row which is the previous row of specified key
- seekToPreviousRow(ExtendedCell) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
- SeenRowTracker(byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.HBaseTestingUtility.SeenRowTracker
-
Deprecated.
- seePastDeleteMarkers - Variable in class org.apache.hadoop.hbase.regionserver.querymatcher.NormalUserScanQueryMatcher
-
whether time range queries can see rows "behind" a delete
- segment - Variable in class org.apache.hadoop.hbase.regionserver.SegmentScanner
- org.apache.hadoop.hbase.regionserver.Segment - Class in org.apache.hadoop.hbase.regionserver
-
This is an abstraction of a segment maintained in a memstore, e.g., the active cell set or its snapshot.
- Segment(CellComparator, List<ImmutableSegment>, TimeRangeTracker) - Constructor for class org.apache.hadoop.hbase.regionserver.Segment
- Segment(CellComparator, TimeRangeTracker) - Constructor for class org.apache.hadoop.hbase.regionserver.Segment
- Segment(CellSet<ExtendedCell>, CellComparator, MemStoreLAB, TimeRangeTracker) - Constructor for class org.apache.hadoop.hbase.regionserver.Segment
- Segment(Segment) - Constructor for class org.apache.hadoop.hbase.regionserver.Segment
- org.apache.hadoop.hbase.regionserver.SegmentFactory - Class in org.apache.hadoop.hbase.regionserver
-
A singleton store segment factory.
- org.apache.hadoop.hbase.regionserver.SegmentScanner - Class in org.apache.hadoop.hbase.regionserver
-
A scanner of a single memstore segment.
- SegmentScanner(Segment, long) - Constructor for class org.apache.hadoop.hbase.regionserver.SegmentScanner
-
Scanners are ordered from 0 (oldest) to newest in increasing order.
- SELECTOR_NUM_OPTION - Static variable in class org.apache.hadoop.hbase.thrift.Constants
- SELECTOR_THREADS_CONF_KEY - Static variable in class org.apache.hadoop.hbase.thrift.HThreadedSelectorServerArgs
-
Number of selector threads for reading and writing socket
- selectScannersFrom(HStore, List<? extends KeyValueScanner>) - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
Filters the given list of scanners using Bloom filter, time range, and TTL.
- selectStoresToFlush() - Method in class org.apache.hadoop.hbase.regionserver.FlushAllLargeStoresPolicy
- selectStoresToFlush() - Method in class org.apache.hadoop.hbase.regionserver.FlushAllStoresPolicy
- selectStoresToFlush() - Method in class org.apache.hadoop.hbase.regionserver.FlushNonSloppyStoresFirstPolicy
-
Returns the stores need to be flushed.
- selectStoresToFlush() - Method in class org.apache.hadoop.hbase.regionserver.FlushPolicy
-
Returns the stores need to be flushed.
- sendResponseIfReady() - Method in interface org.apache.hadoop.hbase.ipc.RpcCall
-
Send the response of this RPC call.
- SENT_BYTES_DESC - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
- SENT_BYTES_NAME - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
- sentBytes(long) - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
- sentBytes(long) - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceImpl
- sentResponse(long) - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
- sentResponse(long) - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceImpl
- SEP - Static variable in class org.apache.hadoop.hbase.mob.MobUtils
- SEPARATE_OLDLOGDIR - Static variable in class org.apache.hadoop.hbase.wal.AbstractFSWALProvider
-
Separate old log into different dir by regionserver name
- separator() - Method in class org.apache.hadoop.hbase.util.RegionSplitter.NumberStringSplit
- separator() - Method in interface org.apache.hadoop.hbase.util.RegionSplitter.SplitAlgorithm
-
Returns the separator character to use when storing / printing the row
- separator() - Method in class org.apache.hadoop.hbase.util.RegionSplitter.UniformSplit
- SEPARATOR_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv
- seqId - Variable in class org.apache.hadoop.hbase.ExtendedCellBuilderImpl
- SEQNUM_QUALIFIER - Static variable in class org.apache.hadoop.hbase.HConstants
-
The open seqnum column qualifier
- SEQNUM_QUALIFIER_STR - Static variable in class org.apache.hadoop.hbase.HConstants
-
The open seqnum column qualifier
- sequenceID - Variable in class org.apache.hadoop.hbase.regionserver.StoreFileReader
- org.apache.hadoop.hbase.regionserver.SequenceId - Interface in org.apache.hadoop.hbase.regionserver
-
Interface which abstracts implementations on log sequenceId assignment
- sequenceIdAccounting - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
Class that does accounting of sequenceids in WAL subsystem.
- org.apache.hadoop.hbase.regionserver.wal.SequenceIdAccounting - Class in org.apache.hadoop.hbase.regionserver.wal
-
Accounting of sequence ids per region and then by column family.
- SequenceIdAccounting() - Constructor for class org.apache.hadoop.hbase.regionserver.wal.SequenceIdAccounting
- sequenceIdChecker - Variable in class org.apache.hadoop.hbase.wal.WALSplitter
- serialize(byte[], Type, JsonSerializationContext) - Method in class org.apache.hadoop.hbase.http.gson.ByteArraySerializer
- serialize(String, Throwable) - Static method in exception org.apache.hadoop.hbase.errorhandling.ForeignException
-
Converts a ForeignException to an array of bytes.
- serialize(ByteBuffer, boolean) - Method in interface org.apache.hadoop.hbase.io.hfile.Cacheable
-
Serializes its data into destination.
- serialize(ByteBuffer, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
- serialize(Cell) - Method in class org.apache.hadoop.hbase.mapreduce.CellSerialization.CellSerializer
- serialize(ExtendedCell) - Method in class org.apache.hadoop.hbase.mapreduce.ExtendedCellSerialization.ExtendedCellSerializer
- serializeMobFileRefs(SetMultimap<TableName, String>) - Static method in class org.apache.hadoop.hbase.mob.MobUtils
-
Serialize a set of referenced mob hfiles
- serializeStateData(ProcedureStateSerializer) - Method in class org.apache.hadoop.hbase.regionserver.storefiletracker.ModifyColumnFamilyStoreFileTrackerProcedure
- serializeStateData(ProcedureStateSerializer) - Method in class org.apache.hadoop.hbase.regionserver.storefiletracker.ModifyStoreFileTrackerProcedure
- serve() - Method in class org.apache.hadoop.hbase.thrift.TBoundedThreadPoolServer
- server - Variable in class org.apache.hadoop.hbase.HBaseRpcServicesBase
- server - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
- org.apache.hadoop.hbase.Server - Interface in org.apache.hadoop.hbase
-
Defines a curated set of shared functions implemented by HBase servers (Masters and RegionServers).
- SERVER_CRASH_METRIC_PREFIX - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
- SERVER_DOES_NOT_MATCH_META - Enum constant in enum class org.apache.hadoop.hbase.util.HbckErrorReporter.ERROR_CODE
-
Deprecated.
- SERVER_NAME_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
- SERVER_NAME_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- SERVER_NAME_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
- SERVER_NAME_NAME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- SERVER_QUALIFIER - Static variable in class org.apache.hadoop.hbase.HConstants
-
The server column qualifier
- SERVER_QUALIFIER_STR - Static variable in class org.apache.hadoop.hbase.HConstants
-
The server column qualifier
- SERVER_TYPE_CONF_KEY - Static variable in class org.apache.hadoop.hbase.thrift.Constants
- serverAdded(ServerName) - Method in interface org.apache.hadoop.hbase.master.ServerListener
-
The server has joined the cluster.
- serverAdded(ServerName) - Method in class org.apache.hadoop.hbase.master.WorkerAssigner
- org.apache.hadoop.hbase.ipc.ServerCall<T extends org.apache.hadoop.hbase.ipc.ServerRpcConnection> - Class in org.apache.hadoop.hbase.ipc
-
Datastructure that holds all necessary to a method invocation and then afterward, carries the result.
- serverChannelClass() - Method in class org.apache.hadoop.hbase.util.NettyEventLoopGroupConfig
- org.apache.hadoop.hbase.util.ServerCommandLine - Class in org.apache.hadoop.hbase.util
-
Base class for command lines that start up various HBase daemons.
- ServerCommandLine() - Constructor for class org.apache.hadoop.hbase.util.ServerCommandLine
- org.apache.hadoop.hbase.http.ServerConfigurationKeys - Interface in org.apache.hadoop.hbase.http
-
This interface contains constants for configuration keys used in the hbase http server code.
- org.apache.hadoop.hbase.master.ServerListener - Interface in org.apache.hadoop.hbase.master
-
Get notification of server registration events.
- org.apache.hadoop.hbase.master.ServerManager - Class in org.apache.hadoop.hbase.master
-
The ServerManager class manages info about region servers.
- ServerManager(MasterServices, RegionServerList) - Constructor for class org.apache.hadoop.hbase.master.ServerManager
-
Constructor.
- org.apache.hadoop.hbase.master.ServerManager.ServerLiveState - Enum Class in org.apache.hadoop.hbase.master
- org.apache.hadoop.hbase.ServerMetrics - Interface in org.apache.hadoop.hbase
-
This class is used for exporting current state of load on a RegionServer.
- org.apache.hadoop.hbase.ServerMetricsBuilder - Class in org.apache.hadoop.hbase
- serverName - Variable in class org.apache.hadoop.hbase.HBaseServerBase
-
The server name the Master sees us as.
- org.apache.hadoop.hbase.ServerName - Class in org.apache.hadoop.hbase
-
Name of a particular incarnation of an HBase Server.
- ServerName(String, int, long) - Constructor for class org.apache.hadoop.hbase.ServerName
- SERVERNAME_PATTERN - Static variable in class org.apache.hadoop.hbase.ServerName
- SERVERNAME_QUALIFIER - Static variable in class org.apache.hadoop.hbase.HConstants
- SERVERNAME_QUALIFIER_STR - Static variable in class org.apache.hadoop.hbase.HConstants
-
The serverName column qualifier.
- SERVERNAME_SEPARATOR - Static variable in class org.apache.hadoop.hbase.ServerName
-
This character is used as separator between server hostname, port and startcode.
- org.apache.hadoop.hbase.regionserver.ServerNonceManager - Class in org.apache.hadoop.hbase.regionserver
-
Implementation of nonce manager that stores nonces in a hash map and cleans them up after some time; if nonce group/client ID is supplied, nonces are stored by client ID.
- ServerNonceManager(Configuration) - Constructor for class org.apache.hadoop.hbase.regionserver.ServerNonceManager
- org.apache.hadoop.hbase.ipc.ServerNotRunningYetException - Exception in org.apache.hadoop.hbase.ipc
- ServerNotRunningYetException(String) - Constructor for exception org.apache.hadoop.hbase.ipc.ServerNotRunningYetException
- serverPrincipal - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
- org.apache.hadoop.hbase.util.ServerRegionReplicaUtil - Class in org.apache.hadoop.hbase.util
-
Similar to
RegionReplicaUtil
but for the server side - ServerRegionReplicaUtil() - Constructor for class org.apache.hadoop.hbase.util.ServerRegionReplicaUtil
- serverRemoved(ServerName) - Method in interface org.apache.hadoop.hbase.master.ServerListener
-
The server was removed from the cluster.
- org.apache.hadoop.hbase.ipc.ServerRpcController - Class in org.apache.hadoop.hbase.ipc
-
Used for server-side protobuf RPC service invocations.
- ServerRpcController() - Constructor for class org.apache.hadoop.hbase.ipc.ServerRpcController
- SERVERS_NAME - Enum constant in enum class org.apache.hadoop.hbase.ClusterMetrics.Option
-
metrics about live region servers name
- SERVERSTART_WAIT_MAX_KEY - Static variable in class org.apache.hadoop.hbase.util.RegionMover
- org.apache.hadoop.hbase.client.backoff.ServerStatistics - Class in org.apache.hadoop.hbase.client.backoff
-
Track the statistics for a single region
- ServerStatistics() - Constructor for class org.apache.hadoop.hbase.client.backoff.ServerStatistics
- org.apache.hadoop.hbase.client.backoff.ServerStatistics.RegionStatistics - Class in org.apache.hadoop.hbase.client.backoff
- org.apache.hadoop.hbase.client.ServerStatisticTracker - Class in org.apache.hadoop.hbase.client
-
Tracks the statistics for multiple regions
- ServerStatisticTracker() - Constructor for class org.apache.hadoop.hbase.client.ServerStatisticTracker
- serversThatCannotSpecifyBindIP() - Static method in enum class org.apache.hadoop.hbase.thrift.ImplType
- org.apache.hadoop.hbase.ServerTask - Interface in org.apache.hadoop.hbase
-
Information about active monitored server tasks
- org.apache.hadoop.hbase.ServerTask.State - Enum Class in org.apache.hadoop.hbase
-
Task state
- org.apache.hadoop.hbase.ServerTaskBuilder - Class in org.apache.hadoop.hbase
-
Builder for information about active monitored server tasks
- org.apache.hadoop.hbase.ipc.ServerTooBusyException - Exception in org.apache.hadoop.hbase.ipc
-
Throw this in RPC call if there are too many pending requests for one region server
- ServerTooBusyException(InetSocketAddress, long) - Constructor for exception org.apache.hadoop.hbase.ipc.ServerTooBusyException
-
Deprecated.
- ServerTooBusyException(Address, long) - Constructor for exception org.apache.hadoop.hbase.ipc.ServerTooBusyException
- org.apache.hadoop.hbase.client.ServerType - Enum Class in org.apache.hadoop.hbase.client
-
Select server type i.e destination for RPC request associated with ring buffer.
- service - Variable in class org.apache.hadoop.hbase.ipc.ServerCall
- service(HttpServletRequest, HttpServletResponse) - Method in class org.apache.hadoop.hbase.rest.RESTServletContainer
-
This container is used only if authentication and impersonation is enabled.
- SERVICE_KEY - Static variable in class org.apache.hadoop.hbase.util.JSONMetricUtil
- org.apache.hadoop.hbase.client.ServiceCaller<S,
R> - Interface in org.apache.hadoop.hbase.client -
Delegate to a protobuf rpc call.
- org.apache.hadoop.hbase.ServiceNotRunningException - Exception in org.apache.hadoop.hbase
- ServiceNotRunningException() - Constructor for exception org.apache.hadoop.hbase.ServiceNotRunningException
- ServiceNotRunningException(String) - Constructor for exception org.apache.hadoop.hbase.ServiceNotRunningException
- ServiceNotRunningException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.ServiceNotRunningException
- ServiceNotRunningException(Throwable) - Constructor for exception org.apache.hadoop.hbase.ServiceNotRunningException
- services - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
- services - Static variable in class org.apache.hadoop.hbase.security.HBasePolicyProvider
- serviceUGI - Variable in class org.apache.hadoop.hbase.thrift.ThriftServer
- Servlet() - Constructor for class org.apache.hadoop.hbase.http.log.LogLevel.Servlet
- SESSION_TIMEOUT_ZK - Static variable in class org.apache.hadoop.hbase.chaos.ChaosConstants
- set(boolean) - Method in class org.apache.hadoop.hbase.master.BooleanStateStore
-
Set the flag on/off.
- set(byte[]) - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
-
Use passed bytes as backing array for this instance.
- set(byte[]) - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
- set(byte[]) - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
- set(byte[]) - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Reuse this
ByteRange
over a new byte[]. - set(byte[]) - Method in class org.apache.hadoop.hbase.util.Bytes
-
Use passed bytes as backing array for this instance.
- set(byte[]) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
- set(byte[]) - Method in class org.apache.hadoop.hbase.util.SimpleByteRange
- set(byte[]) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
- set(byte[]) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
- set(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
-
Use passed bytes as backing array for this instance.
- set(byte[], int, int) - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
- set(byte[], int, int) - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
- set(byte[], int, int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Reuse this
ByteRange
over a new byte[]. - set(byte[], int, int) - Method in class org.apache.hadoop.hbase.util.Bytes
-
Use passed bytes as backing array for this instance.
- set(byte[], int, int) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
- set(byte[], int, int) - Method in class org.apache.hadoop.hbase.util.SimpleByteRange
- set(byte[], int, int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
- set(byte[], int, int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
- set(int) - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
- set(int) - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
- set(int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Reuse this
ByteRange
over a new byte[]. - set(int) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
- set(int) - Method in class org.apache.hadoop.hbase.util.SimpleByteRange
- set(int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
- set(int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
- set(int, E) - Method in class org.apache.hadoop.hbase.util.SortedList
- set(long, TimeUnit) - Method in class org.apache.hadoop.hbase.quotas.RateLimiter
-
Set the RateLimiter max available resources and refill period.
- set(String, String) - Method in class org.apache.hadoop.hbase.CompoundConfiguration
- set(String, String) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
- set(String, String, String) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
- set(List<StoreFileInfo>) - Method in interface org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileTracker
-
Set the store files.
- set(Attributes) - Method in class org.apache.hadoop.hbase.hbtop.terminal.Attributes
- set(Cell) - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.Cell
- set(KeyValue.KeyOnlyKeyValue) - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
- SET - Enum constant in enum class org.apache.hadoop.hbase.backup.BackupRestoreConstants.BackupCommand
- SET_ADD - Enum constant in enum class org.apache.hadoop.hbase.backup.BackupRestoreConstants.BackupCommand
- SET_DELETE - Enum constant in enum class org.apache.hadoop.hbase.backup.BackupRestoreConstants.BackupCommand
- SET_DESCRIBE - Enum constant in enum class org.apache.hadoop.hbase.backup.BackupRestoreConstants.BackupCommand
- SET_LIST - Enum constant in enum class org.apache.hadoop.hbase.backup.BackupRestoreConstants.BackupCommand
- SET_REMOVE - Enum constant in enum class org.apache.hadoop.hbase.backup.BackupRestoreConstants.BackupCommand
- SET_STATUS_SLEEP_TIME - Static variable in class org.apache.hadoop.hbase.chaos.ChaosConstants
- setAbortRequested() - Method in class org.apache.hadoop.hbase.HBaseServerBase
-
Sets the abort state if not already set.
- setAcl(String, List<ACL>, int) - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
setAcl is an idempotent operation.
- setACL(String, Permission) - Method in class org.apache.hadoop.hbase.client.Append
- setACL(String, Permission) - Method in class org.apache.hadoop.hbase.client.Delete
- setACL(String, Permission) - Method in class org.apache.hadoop.hbase.client.Get
- setACL(String, Permission) - Method in class org.apache.hadoop.hbase.client.ImmutableScan
- setACL(String, Permission) - Method in class org.apache.hadoop.hbase.client.Increment
- setACL(String, Permission) - Method in class org.apache.hadoop.hbase.client.Mutation
-
Set the ACL for this operation.
- setACL(String, Permission) - Method in class org.apache.hadoop.hbase.client.Put
- setACL(String, Permission) - Method in class org.apache.hadoop.hbase.client.Query
-
Set the ACL for the operation.
- setACL(String, Permission) - Method in class org.apache.hadoop.hbase.client.Scan
- setACL(Map<String, Permission>) - Method in class org.apache.hadoop.hbase.client.Append
- setACL(Map<String, Permission>) - Method in class org.apache.hadoop.hbase.client.Delete
- setACL(Map<String, Permission>) - Method in class org.apache.hadoop.hbase.client.Get
- setACL(Map<String, Permission>) - Method in class org.apache.hadoop.hbase.client.ImmutableScan
- setACL(Map<String, Permission>) - Method in class org.apache.hadoop.hbase.client.Increment
- setACL(Map<String, Permission>) - Method in class org.apache.hadoop.hbase.client.Mutation
-
Set the ACL for this operation.
- setACL(Map<String, Permission>) - Method in class org.apache.hadoop.hbase.client.Put
- setACL(Map<String, Permission>) - Method in class org.apache.hadoop.hbase.client.Query
-
Set the ACL for the operation.
- setACL(Map<String, Permission>) - Method in class org.apache.hadoop.hbase.client.Scan
- setACL(AccessControlList) - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
- setAgeOfLastAppliedOp(long) - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSink.ReplicationLoadSinkBuilder
- setAgeOfLastShippedOp(long) - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSource.ReplicationLoadSourceBuilder
- setAllLevels(String, String) - Static method in class org.apache.hadoop.hbase.logging.Log4jUtils
- setAllowFastReflectionFallthrough(boolean) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
- setAllowNullValueProperties(boolean) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
- setAllowPartialResults(boolean) - Method in class org.apache.hadoop.hbase.client.ImmutableScan
- setAllowPartialResults(boolean) - Method in class org.apache.hadoop.hbase.client.Scan
-
Setting whether the caller wants to see the partial results when server returns less-than-expected cells.
- setAppDir(String) - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
- setAsyncPrefetch(boolean) - Method in class org.apache.hadoop.hbase.client.ImmutableScan
-
Deprecated.
- setAsyncPrefetch(boolean) - Method in class org.apache.hadoop.hbase.client.Scan
-
Deprecated.Since 3.0.0, will be removed in 4.0.0. After building sync client upon async client, the implementation is always 'async prefetch', so this flag is useless now.
- setAttribute(String, byte[]) - Method in class org.apache.hadoop.hbase.client.Append
- setAttribute(String, byte[]) - Method in interface org.apache.hadoop.hbase.client.Attributes
-
Sets an attribute.
- setAttribute(String, byte[]) - Method in class org.apache.hadoop.hbase.client.Delete
- setAttribute(String, byte[]) - Method in class org.apache.hadoop.hbase.client.Get
- setAttribute(String, byte[]) - Method in class org.apache.hadoop.hbase.client.ImmutableScan
- setAttribute(String, byte[]) - Method in class org.apache.hadoop.hbase.client.Increment
- setAttribute(String, byte[]) - Method in class org.apache.hadoop.hbase.client.OperationWithAttributes
- setAttribute(String, byte[]) - Method in class org.apache.hadoop.hbase.client.Put
- setAttribute(String, byte[]) - Method in class org.apache.hadoop.hbase.client.Scan
- setAttribute(String, Object) - Method in class org.apache.hadoop.hbase.http.HttpServer
-
Set a value in the webapp context.
- setAttribute(String, Object) - Method in class org.apache.hadoop.hbase.http.InfoServer
- setAttributes(Attributes) - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.Cell
- setAuthorizations(Authorizations) - Method in class org.apache.hadoop.hbase.client.Get
- setAuthorizations(Authorizations) - Method in class org.apache.hadoop.hbase.client.ImmutableScan
- setAuthorizations(Authorizations) - Method in class org.apache.hadoop.hbase.client.Query
-
Sets the authorizations to be used by this Query
- setAuthorizations(Authorizations) - Method in class org.apache.hadoop.hbase.client.Scan
- setBackerMasterNames(List<ServerName>) - Method in class org.apache.hadoop.hbase.ClusterMetricsBuilder
- setBackgroundColor(Color) - Method in class org.apache.hadoop.hbase.hbtop.terminal.Attributes
- setBackoffPolicy(RetryCounter.BackoffPolicy) - Method in class org.apache.hadoop.hbase.util.RetryCounter.RetryConfig
- setBackupId(String) - Method in class org.apache.hadoop.hbase.backup.BackupInfo
- setBackupRootDir(String) - Method in class org.apache.hadoop.hbase.backup.BackupInfo
- setBackupTableInfoMap(Map<TableName, BackupTableInfo>) - Method in class org.apache.hadoop.hbase.backup.BackupInfo
- setBalancerDecisions(List<RecentLogs.BalancerDecision>) - Method in class org.apache.hadoop.hbase.namequeues.response.NamedQueueGetResponse
- setBalancerDecisionsRequest(MasterProtos.BalancerDecisionsRequest) - Method in class org.apache.hadoop.hbase.namequeues.request.NamedQueueGetRequest
- setBalancerOn(Boolean) - Method in class org.apache.hadoop.hbase.ClusterMetricsBuilder
- setBalancerRan(boolean) - Method in class org.apache.hadoop.hbase.client.BalanceResponse.Builder
-
Set true if the balancer ran, otherwise false.
- setBalancerRejections(List<RecentLogs.BalancerRejection>) - Method in class org.apache.hadoop.hbase.namequeues.response.NamedQueueGetResponse
- setBalancerRejectionsRequest(MasterProtos.BalancerRejectionsRequest) - Method in class org.apache.hadoop.hbase.namequeues.request.NamedQueueGetRequest
- setBalancerRunning(RpcController, MasterProtos.SetBalancerRunningRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- setBandwidth(long) - Method in class org.apache.hadoop.hbase.backup.BackupInfo
- setBandwidth(long) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeerConfigBuilder
-
Sets the speed, in bytes per second, for any one RegionServer to replicate data to the peer.
- setBatch(int) - Method in class org.apache.hadoop.hbase.client.ImmutableScan
- setBatch(int) - Method in class org.apache.hadoop.hbase.client.Scan
-
Set the maximum number of cells to return for each call to next().
- setBatchLimit(int) - Method in class org.apache.hadoop.hbase.regionserver.ScannerContext.Builder
- setBatchUpdate(boolean) - Method in class org.apache.hadoop.hbase.util.MultiThreadedUpdater
-
Use batch vs.
- setBindAddress(String) - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
-
Deprecated.Since 0.99.0. Use
HttpServer.Builder.addEndpoint(URI)
instead. - setBlink(boolean) - Method in class org.apache.hadoop.hbase.hbtop.terminal.Attributes
- setBlockBytesScanned(long) - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord.OnlineLogRecordBuilder
-
Sets the amount of block bytes scanned to retrieve the response cells.
- setBlockCache(BlockCache) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Only used for unit test which doesn't start region server.
- setBlockCacheEnabled(boolean) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
- setBlockCacheSize(float) - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerResult
- setBlockedFlushCount(long) - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerContext
- setBlocksize(int) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
- setBlocksize(String) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
- setBlocksLocalWeight(long) - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder
- setBlocksLocalWithSsdWeight(long) - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder
- setBlocksTotalWeight(long) - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder
- setBlockType(BlockType) - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheKey
- setBloomFilterSize(Size) - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder
- setBloomFilterType(BloomType) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
- setBody(byte[]) - Method in class org.apache.hadoop.hbase.rest.client.Response
- setBold(boolean) - Method in class org.apache.hadoop.hbase.hbtop.terminal.Attributes
- setBoolean(String, boolean) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
- setBooleanIfUnset(String, boolean) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
- setBulkLoaded(boolean) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileReader
- setCacheBlocks(boolean) - Method in class org.apache.hadoop.hbase.client.Get
-
Set whether blocks should be cached for this Get.
- setCacheBlocks(boolean) - Method in class org.apache.hadoop.hbase.client.ImmutableScan
- setCacheBlocks(boolean) - Method in class org.apache.hadoop.hbase.client.Scan
-
Set whether blocks should be cached for this Scan.
- setCacheBloomsOnWrite(boolean) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
- setCacheDataOnWrite(boolean) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
- setCacheDataOnWrite(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
- setCacheIndexesOnWrite(boolean) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
- setCacheMissCount(long) - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerContext
- setCacheMobBlocks(Scan, boolean) - Static method in class org.apache.hadoop.hbase.mob.MobUtils
-
Sets the attribute of caching blocks in the scan.
- setCaching(int) - Method in class org.apache.hadoop.hbase.client.ImmutableScan
- setCaching(int) - Method in class org.apache.hadoop.hbase.client.Scan
-
Set the number of rows for caching that will be passed to scanners.
- setCallBack(RpcCallback) - Method in interface org.apache.hadoop.hbase.ipc.RpcCallContext
-
Sets a callback which has to be executed at the end of this RPC call.
- setCallBack(RpcCallback) - Method in class org.apache.hadoop.hbase.ipc.ServerCall
- setCallDetails(String) - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord.OnlineLogRecordBuilder
- setCallQueueLen(int) - Method in interface org.apache.hadoop.hbase.thrift.MetricsThriftServerSource
-
Set the call queue length.
- setCallQueueLen(int) - Method in class org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceImpl
- setCallQueueLen(int) - Method in class org.apache.hadoop.hbase.thrift.ThriftMetrics
- setCallTimeMs(long) - Method in class org.apache.hadoop.hbase.client.MetricsConnection.CallStats
- setCallTimeout(int) - Method in class org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
- setCallTimeout(int) - Method in interface org.apache.hadoop.hbase.ipc.HBaseRpcController
- setCallTimeout(int) - Method in class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
- setCatalogJanitorChoreForTesting(CatalogJanitor) - Method in class org.apache.hadoop.hbase.master.HMaster
-
Used for testing only to set Mock objects.
- setCatalogJanitorEnabled(boolean) - Method in class org.apache.hadoop.hbase.master.HMaster
-
Switch for the background CatalogJanitor thread.
- setCellScanner(ExtendedCellScanner) - Method in class org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
- setCellScanner(ExtendedCellScanner) - Method in interface org.apache.hadoop.hbase.ipc.HBaseRpcController
-
Only used to send cells to rpc server, the returned cells should be set by
HBaseRpcController.setDone(ExtendedCellScanner)
. - setCellScanner(ExtendedCellScanner) - Method in class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
- setCellSet(CellSet<ExtendedCell>, CellSet<ExtendedCell>) - Method in class org.apache.hadoop.hbase.regionserver.Segment
-
Setting the CellSet of the segment - used only for flat immutable segment for setting immutable CellSet after its creation in immutable segment constructor
- setCellSet(CellSet, CellSet) - Method in class org.apache.hadoop.hbase.regionserver.CompositeImmutableSegment
-
Setting the CellSet of the segment - used only for flat immutable segment for setting immutable CellSet after its creation in immutable segment constructor
- setCellVisibility(CellVisibility) - Method in class org.apache.hadoop.hbase.client.Append
- setCellVisibility(CellVisibility) - Method in class org.apache.hadoop.hbase.client.Delete
- setCellVisibility(CellVisibility) - Method in class org.apache.hadoop.hbase.client.Increment
- setCellVisibility(CellVisibility) - Method in class org.apache.hadoop.hbase.client.Mutation
-
Sets the visibility expression associated with cells in this Mutation.
- setCellVisibility(CellVisibility) - Method in class org.apache.hadoop.hbase.client.Put
- setChance(float) - Method in class org.apache.hadoop.hbase.filter.RandomRowFilter
-
Set the chance that a row is included.
- setChar(char) - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.Cell
- setCharset(Charset) - Method in class org.apache.hadoop.hbase.filter.RegexStringComparator
-
Specifies the
Charset
to use to convert the row key to a String. - setCheckExistenceOnly(boolean) - Method in class org.apache.hadoop.hbase.client.Get
- setCheckHdfs(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- setCipher(Cipher) - Method in class org.apache.hadoop.hbase.io.crypto.Context
- setCipher(Cipher) - Method in class org.apache.hadoop.hbase.io.crypto.Encryption.Context
- setClass(String, Class<?>, Class<?>) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
- setClassLoader(ClassLoader) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
- setCleanerChoreRunning(RpcController, MasterProtos.SetCleanerChoreRunningRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- setCleanReplicationBarrier(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- setCleanReplicationBarrierTable(String) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- setClientAddress(String) - Method in class org.apache.hadoop.hbase.client.LogQueryFilter
-
Deprecated.
- setClientAddress(String) - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord.OnlineLogRecordBuilder
- setClosedRegions(int) - Method in class org.apache.hadoop.hbase.client.RegionStatesCount.RegionStatesCountBuilder
- setClosing(boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Exposed for some very specific unit tests.
- setCluster(Cluster) - Method in class org.apache.hadoop.hbase.rest.client.Client
- setClusterDown() - Method in class org.apache.hadoop.hbase.zookeeper.ClusterStatusTracker
-
Sets the cluster as down by deleting the znode.
- setClusterId(String) - Method in class org.apache.hadoop.hbase.ClusterMetricsBuilder
- setClusterId(FileSystem, Path, ClusterId, long) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Writes a new unique identifier for this cluster to the "hbase.id" file in the HBase root directory.
- setClusterId(ZKWatcher, ClusterId) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKClusterId
- setClusterIds(List<UUID>) - Method in class org.apache.hadoop.hbase.client.Append
- setClusterIds(List<UUID>) - Method in class org.apache.hadoop.hbase.client.Delete
- setClusterIds(List<UUID>) - Method in class org.apache.hadoop.hbase.client.Increment
- setClusterIds(List<UUID>) - Method in class org.apache.hadoop.hbase.client.Mutation
-
Marks that the clusters with the given clusterIds have consumed the mutation
- setClusterIds(List<UUID>) - Method in class org.apache.hadoop.hbase.client.Put
- setClusterInfoProvider(ClusterInfoProvider) - Method in interface org.apache.hadoop.hbase.master.LoadBalancer
-
Set the cluster info provider.
- setClusterInfoProvider(ClusterInfoProvider) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupBasedLoadBalancer
- setClusterKey(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeerConfigBuilder
-
Set the clusterKey which is the concatenation of the slave cluster's: hbase.zookeeper.quorum:hbase.zookeeper.property.clientPort:zookeeper.znode.parent
- setClusterUp() - Method in class org.apache.hadoop.hbase.zookeeper.ClusterStatusTracker
-
Sets the cluster as up.
- setCode(int) - Method in class org.apache.hadoop.hbase.rest.client.Response
- setColumnFamilies(Collection<ColumnFamilyDescriptor>) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
- setColumnFamily(ColumnFamilyDescriptor) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
- setColumnFamilyTimeRange(byte[], long, long) - Method in class org.apache.hadoop.hbase.client.Get
- setColumnFamilyTimeRange(byte[], long, long) - Method in class org.apache.hadoop.hbase.client.ImmutableScan
- setColumnFamilyTimeRange(byte[], long, long) - Method in class org.apache.hadoop.hbase.client.Query
-
Get versions of columns only within the specified timestamp range, [minStamp, maxStamp) on a per CF bases.
- setColumnFamilyTimeRange(byte[], long, long) - Method in class org.apache.hadoop.hbase.client.Scan
- setCompactedCellCount(long) - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder
- setCompactingCellCount(long) - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder
- setCompactionCompressionType(Compression.Algorithm) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
- setCompactionEnabled(boolean) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
- setCompactionsEnabled(boolean) - Method in class org.apache.hadoop.hbase.regionserver.CompactSplit
- setCompactionState(CompactionState) - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder
- setComparatorClass(Class<? extends CellComparator>) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
- setCompletedSequenceId(long) - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder
- setCompleteTs(long) - Method in class org.apache.hadoop.hbase.backup.BackupInfo
- setCompletionTime(long) - Method in class org.apache.hadoop.hbase.ServerTaskBuilder
- setCompositeSnapshot(boolean) - Method in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
- setCompressionCodec(Compression.Algorithm) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
- setCompressionType(Compression.Algorithm) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
- setCompressTags(boolean) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
- setCompressTags(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
- setComputedSteps(long) - Method in class org.apache.hadoop.hbase.client.BalancerDecision.Builder
- setComputedTotalCost(double) - Method in class org.apache.hadoop.hbase.client.BalancerDecision.Builder
- setConcurrentCallsPerServer(int) - Method in class org.apache.hadoop.hbase.client.MetricsConnection.CallStats
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.backup.BackupHFileCleaner
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.BaseConfigurable
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.HBaseCluster
-
Deprecated.
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.io.crypto.Context
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.io.crypto.CryptoCipherProvider
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.io.crypto.DefaultCipherProvider
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.mapreduce.DefaultVisibilityExpressionResolver
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.mapreduce.GroupingTableMapper
-
Sets the configuration.
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.mapreduce.HRegionPartitioner
-
Sets the configuration.
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableInputFormat
-
Sets the configuration.
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.mapreduce.SimpleTotalOrderPartitioner
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
Sets the configuration.
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputFormat
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareCompactionThroughputController
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareFlushThroughputController
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.ScanPerformanceEvaluation
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.security.UserProvider
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.util.MapreduceDependencyClasspathTool
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.wal.WALPerformanceEvaluation
- setConfiguration(String, String) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
- setConfiguration(String, String) - Method in class org.apache.hadoop.hbase.NamespaceDescriptor
-
Setter for storing a configuration setting in
NamespaceDescriptor.configuration
map. - setConfiguration(String, String) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
-
Setter for storing a configuration setting in
RSGroupInfo.configuration
map. - setConflictWaitIterationMs(int) - Method in class org.apache.hadoop.hbase.regionserver.ServerNonceManager
- setConnectionAttributes(Map<String, byte[]>) - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord.OnlineLogRecordBuilder
- setConsistency(Consistency) - Method in class org.apache.hadoop.hbase.client.Get
- setConsistency(Consistency) - Method in class org.apache.hadoop.hbase.client.ImmutableScan
- setConsistency(Consistency) - Method in class org.apache.hadoop.hbase.client.Query
-
Sets the consistency level for this operation
- setConsistency(Consistency) - Method in class org.apache.hadoop.hbase.client.Scan
- setContainerOperations(Collection<? extends Row>) - Method in class org.apache.hadoop.hbase.client.trace.TableOperationSpanBuilder
- setContainerOperations(Row) - Method in class org.apache.hadoop.hbase.client.trace.TableOperationSpanBuilder
- setContainerOperations(RowMutations) - Method in class org.apache.hadoop.hbase.client.trace.TableOperationSpanBuilder
- setContainerOperations(HBaseSemanticAttributes.Operation...) - Method in class org.apache.hadoop.hbase.client.trace.TableOperationSpanBuilder
- setControllerException(RpcController, IOException) - Static method in class org.apache.hadoop.hbase.ipc.CoprocessorRpcUtils
-
Stores an exception encountered during RPC invocation so it can be passed back through to the client.
- setControllerException(RpcController, IOException) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ResponseConverter
-
Stores an exception encountered during RPC invocation so it can be passed back through to the client.
- setCoprocessor(String) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
- setCoprocessor(CoprocessorDescriptor) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
- setCoprocessorHost(RegionCoprocessorHost) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
- setCoprocessorNames(List<String>) - Method in class org.apache.hadoop.hbase.ServerMetricsBuilder
- setCoprocessors(Collection<CoprocessorDescriptor>) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
- setCorePoolSize(int) - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
- setCorePoolSize(int) - Method in interface org.apache.hadoop.hbase.thrift.IncrementCoalescerMBean
- setCostFuncInfoList(List<String>) - Method in class org.apache.hadoop.hbase.client.BalancerRejection.Builder
- setCpRequestCount(long) - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder
- setCurBlockCacheSize(float) - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerContext
- setCurBlockCacheSizeGauge(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManager
-
Set the current blockcache size used gauge
- setCurBlockCacheSizeGauge(long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSource
-
Set the current blockcache size used gauge
- setCurBlockCacheSizeGauge(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSourceImpl
- setCurBlockCacheUsed(float) - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerContext
- setCurMemStoreOffHeapSizeGauge(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManager
-
Set the current global memstore off-heap size gauge
- setCurMemStoreOffHeapSizeGauge(long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSource
-
Set the current global memstore off-heap size used gauge
- setCurMemStoreOffHeapSizeGauge(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSourceImpl
- setCurMemStoreOnHeapSizeGauge(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManager
-
Set the current global memstore on-heap size gauge
- setCurMemStoreOnHeapSizeGauge(long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSource
-
Set the current global memstore on-heap size used gauge
- setCurMemStoreOnHeapSizeGauge(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSourceImpl
- setCurMemStoreSize(float) - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerContext
- setCurMemStoreSizeGauge(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManager
-
Set the current global memstore size used gauge
- setCurMemStoreSizeGauge(long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSource
-
Set the current global memstore size used gauge
- setCurMemStoreSizeGauge(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSourceImpl
- setCurMemStoreUsed(float) - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerContext
- setCurrentBuffer(ByteBuff) - Method in interface org.apache.hadoop.hbase.io.encoding.DataBlockEncoder.EncodedSeeker
-
Set on which buffer there will be done seeking.
- setCurrentBuffer(ByteBuff) - Method in class org.apache.hadoop.hbase.io.encoding.RowIndexSeekerV1
- setCurrentCall(RpcCall) - Static method in class org.apache.hadoop.hbase.ipc.RpcServer
-
Used by
RegionProcedureStore
. - setCurrentCell(ExtendedCell) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
- setCurrentRegionCachedRatio(float) - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder
- setCurrentState(String, SpaceQuotaSnapshot) - Method in class org.apache.hadoop.hbase.quotas.NamespaceQuotaSnapshotStore
- setCurrentState(TableName, SpaceQuotaSnapshot) - Method in class org.apache.hadoop.hbase.quotas.TableQuotaSnapshotStore
- setCurrentState(T, SpaceQuotaSnapshot) - Method in interface org.apache.hadoop.hbase.quotas.QuotaSnapshotStore
-
Persists the current
SpaceQuotaSnapshot
for thesubject
. - setCursorPosition(int, int) - Method in class org.apache.hadoop.hbase.hbtop.screen.AbstractScreenView
- setCursorPosition(int, int) - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.batch.BatchTerminal
- setCursorPosition(int, int) - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.ScreenBuffer
- setCursorPosition(int, int) - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.TerminalImpl
- setCursorPosition(int, int) - Method in interface org.apache.hadoop.hbase.hbtop.terminal.Terminal
- setCurTaskZKVersion(MutableInt) - Method in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination.ZkSplitTaskDetails
- setDaemonThreadRunning(T) - Static method in class org.apache.hadoop.hbase.util.Threads
-
Utility method that sets name, daemon status and starts passed thread.
- setDaemonThreadRunning(T, String) - Static method in class org.apache.hadoop.hbase.util.Threads
-
Utility method that sets name, daemon status and starts passed thread.
- setDaemonThreadRunning(T, String, Thread.UncaughtExceptionHandler) - Static method in class org.apache.hadoop.hbase.util.Threads
-
Utility method that sets name, daemon status and starts passed thread.
- setData(String, byte[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp
-
Returns a setData ZKUtilOp
- setData(String, byte[], int) - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
setData is NOT an idempotent operation.
- setData(String, byte[], int) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp
-
Returns a setData ZKUtilOp
- setData(ZKWatcher, String, byte[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Sets the data of the existing znode to be the specified data.
- setData(ZKWatcher, String, byte[], int) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Sets the data of the existing znode to be the specified data.
- setDataBlockEncoder(HFileDataBlockEncoder) - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
- setDataBlockEncoder(HFileDataBlockEncoder) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
- setDataBlockEncoding(DataBlockEncoding) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
- setDataBlockIndexReader(HFileBlockIndex.CellBasedKeyBlockIndexReader) - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
- setDataBlockIndexReader(HFileBlockIndex.CellBasedKeyBlockIndexReader) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
- setDataIndexCount(int) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
- setDataLocality(float) - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder
- setDataLocalityForSsd(float) - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder
- setDeadServerNames(List<ServerName>) - Method in class org.apache.hadoop.hbase.ClusterMetricsBuilder
- setDecommissionedServerNames(List<ServerName>) - Method in class org.apache.hadoop.hbase.ClusterMetricsBuilder
- setDefaultClientPort(int) - Method in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
- setDelegate(InputStream) - Method in class org.apache.hadoop.hbase.io.DelegatingInputStream
- setDeletedTable(TableName) - Method in class org.apache.hadoop.hbase.master.TableStateManager
- setDeprecatedProperties() - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
- setDescription(String) - Method in class org.apache.hadoop.hbase.ServerTaskBuilder
- setDestination(ServerName) - Method in class org.apache.hadoop.hbase.master.RegionPlan
-
Set the destination server for the plan for this region.
- setDetails(SplitLogManagerCoordination.SplitLogManagerDetails) - Method in interface org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination
-
Deprecated.Provide the configuration from the SplitLogManager
- setDetails(SplitLogManagerCoordination.SplitLogManagerDetails) - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
- setDFSCluster(MiniDFSCluster) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- setDFSCluster(MiniDFSCluster, boolean) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Set the MiniDFSCluster
- setDFSReplication(short) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
- setDisplayFullReport() - Static method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.Display the full report from fsck.
- setDone(ExtendedCellScanner) - Method in class org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
- setDone(ExtendedCellScanner) - Method in interface org.apache.hadoop.hbase.ipc.HBaseRpcController
-
IMPORTANT: always call this method if the call finished without any exception to tell the
HBaseRpcController
that we are done. - setDone(ExtendedCellScanner) - Method in class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
- setDouble(String, double) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
- setDropBehind(Boolean) - Method in class org.apache.hadoop.hbase.io.FileLink.FileLinkInputStream
- setDryRun(boolean) - Method in class org.apache.hadoop.hbase.client.BalanceRequest.Builder
-
Updates BalancerRequest to run the balancer in dryRun mode.
- setDurability(Durability) - Method in class org.apache.hadoop.hbase.client.Append
- setDurability(Durability) - Method in class org.apache.hadoop.hbase.client.Delete
- setDurability(Durability) - Method in class org.apache.hadoop.hbase.client.Increment
- setDurability(Durability) - Method in class org.apache.hadoop.hbase.client.Mutation
-
Set the durability for this mutation
- setDurability(Durability) - Method in class org.apache.hadoop.hbase.client.Put
- setDurability(Durability) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
- setEditsRead(long) - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSource.ReplicationLoadSourceBuilder
- setEditsSinceRestart(boolean) - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSource.ReplicationLoadSourceBuilder
- setEffectiveUser(String) - Method in class org.apache.hadoop.hbase.thrift.HBaseServiceHandler
- setEffectiveUser(String) - Method in class org.apache.hadoop.hbase.util.ConnectionCache
-
Set the current thread local effective user
- setEmptyRegionInfoRegions(int) - Method in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
-
Set the number of regions with empty region info.
- setEmptyRegionInfoRegions(int) - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManagerSourceImpl
- setEnabled(boolean) - Method in class org.apache.hadoop.hbase.regionserver.BrokenStoreFileCleaner
- setEncodingState(EncodingState) - Method in class org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultEncodingContext
- setEncodingState(EncodingState) - Method in interface org.apache.hadoop.hbase.io.encoding.HFileBlockEncodingContext
-
Sets the encoding state.
- setEncryptionContext(Encryption.Context) - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
- setEncryptionKey(byte[]) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
- setEncryptionKey(byte[]) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
- setEncryptionType(String) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
- setEndKey(byte[]) - Method in class org.apache.hadoop.hbase.client.RegionInfoBuilder
- setEndKey(Configuration, byte[]) - Static method in class org.apache.hadoop.hbase.mapreduce.SimpleTotalOrderPartitioner
- setEndRow(byte[]) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
- setEndRow(byte[]) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
- setEndTime(long) - Method in class org.apache.hadoop.hbase.rest.RowSpec
- setEntries(List<WAL.Entry>) - Method in class org.apache.hadoop.hbase.replication.ReplicationEndpoint.ReplicateContext
- setEntry(SingleResponse.Entry) - Method in class org.apache.hadoop.hbase.client.SingleResponse
- setEntryCount(long) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
- setEnum(String, T) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
- setErasureCodingPolicy(String) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
- setErrorHandler(HBaseRPCErrorHandler) - Method in class org.apache.hadoop.hbase.ipc.RpcServer
-
Set the handler for calling out of RPC for error conditions.
- setErrorHandler(HBaseRPCErrorHandler) - Method in interface org.apache.hadoop.hbase.ipc.RpcServerInterface
- setEventLoopConfig(Configuration, EventLoopGroup, Class<? extends Channel>) - Static method in class org.apache.hadoop.hbase.ipc.NettyRpcClientConfigHelper
-
Set the EventLoopGroup and channel class for
AsyncRpcClient
. - setEventLoopConfig(Configuration, EventLoopGroup, Class<? extends Channel>) - Static method in class org.apache.hadoop.hbase.wal.NettyAsyncFSWALConfigHelper
-
Set the EventLoopGroup and channel class for
AsyncFSWALProvider
. - setEvictBlocksOnClose(boolean) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
- setEvictCount(long) - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerContext
- setEvictOnClose(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
Only used for testing.
- setExcludeNamespaces(Set<String>) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeerConfigBuilder
-
Sets the collection of namespaces which should not be replicated when all user tables are configured to be replicated.
- setExcludeTableCFsMap(Map<TableName, List<String>>) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeerConfigBuilder
-
Sets the mapping of table name to column families which should not be replicated.
- setExists(Boolean) - Method in class org.apache.hadoop.hbase.client.Result
- setExtendedCells(WALEdit, ArrayList<ExtendedCell>) - Static method in class org.apache.hadoop.hbase.wal.WALEditInternalHelper
- setFailed(IOException) - Method in class org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
- setFailed(IOException) - Method in interface org.apache.hadoop.hbase.ipc.HBaseRpcController
-
Set failed with an exception to pass on.
- setFailed(IOException) - Method in class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
- setFailed(String) - Method in class org.apache.hadoop.hbase.client.ClientCoprocessorRpcController
- setFailed(String) - Method in class org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
- setFailed(String) - Method in class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
- setFailed(String) - Method in class org.apache.hadoop.hbase.ipc.ServerRpcController
- setFailed(Throwable) - Method in class org.apache.hadoop.hbase.client.ClientCoprocessorRpcController
- setFailedMsg(String) - Method in class org.apache.hadoop.hbase.backup.BackupInfo
- setFailedOn(IOException) - Method in class org.apache.hadoop.hbase.ipc.ServerRpcController
-
Sets an exception to be communicated back to the
Service
client. - setFamily(byte[]) - Method in interface org.apache.hadoop.hbase.CellBuilder
- setFamily(byte[]) - Method in interface org.apache.hadoop.hbase.ExtendedCellBuilder
- setFamily(byte[]) - Method in class org.apache.hadoop.hbase.ExtendedCellBuilderImpl
- setFamily(byte[]) - Method in interface org.apache.hadoop.hbase.RawCellBuilder
- setFamily(byte[], int, int) - Method in interface org.apache.hadoop.hbase.CellBuilder
- setFamily(byte[], int, int) - Method in interface org.apache.hadoop.hbase.ExtendedCellBuilder
- setFamily(byte[], int, int) - Method in class org.apache.hadoop.hbase.ExtendedCellBuilderImpl
- setFamily(byte[], int, int) - Method in interface org.apache.hadoop.hbase.RawCellBuilder
- setFamilyMap(Map<byte[], NavigableSet<byte[]>>) - Method in class org.apache.hadoop.hbase.client.ImmutableScan
- setFamilyMap(Map<byte[], NavigableSet<byte[]>>) - Method in class org.apache.hadoop.hbase.client.Scan
-
Setting the familyMap
- setFavoredNodesManager(FavoredNodesManager) - Method in class org.apache.hadoop.hbase.favored.FavoredNodeLoadBalancer
- setFavoredNodesManager(FavoredNodesManager) - Method in interface org.apache.hadoop.hbase.favored.FavoredNodesPromoter
- setFileCreateTime(long) - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
- setFileInfoOffset(long) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
- setFileSystem(FileSystem) - Method in class org.apache.hadoop.hbase.MockRegionServerServices
- setFileSystemURI(String) - Static method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- setFilter(Filter) - Method in class org.apache.hadoop.hbase.client.Get
- setFilter(Filter) - Method in class org.apache.hadoop.hbase.client.ImmutableScan
- setFilter(Filter) - Method in class org.apache.hadoop.hbase.client.Query
-
Apply the specified server-side filter when performing the Query.
- setFilter(Filter) - Method in class org.apache.hadoop.hbase.client.Scan
- setFilterByOperator(LogQueryFilter.FilterByOperator) - Method in class org.apache.hadoop.hbase.client.LogQueryFilter
-
Deprecated.
- setFilteredReadRequestCount(long) - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder
- setFilterEmptyEntry(boolean) - Method in class org.apache.hadoop.hbase.replication.ChainWALEmptyEntryFilter
-
To allow the empty entries to get filtered, we want to set this optional flag to decide if we want to filter the entries which have no cells or all cells got filtered though
WALCellFilter
. - setFilterIfMissing(boolean) - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
Set whether entire row should be filtered if column is not found.
- setFinalFunctionCosts(String) - Method in class org.apache.hadoop.hbase.client.BalancerDecision.Builder
- setFindPort(boolean) - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
- setFirst(A) - Method in class org.apache.hadoop.hbase.util.Triple
- setFirst(T) - Method in class org.apache.hadoop.hbase.util.ObjectIntPair
- setFirst(T1) - Method in class org.apache.hadoop.hbase.util.Pair
-
Replace the first element of the pair.
- setFirstDataBlockOffset(long) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
- setFirstRow(byte[]) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.NumberStringSplit
- setFirstRow(byte[]) - Method in interface org.apache.hadoop.hbase.util.RegionSplitter.SplitAlgorithm
-
Set the first row
- setFirstRow(byte[]) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.UniformSplit
- setFirstRow(String) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.NumberStringSplit
- setFirstRow(String) - Method in interface org.apache.hadoop.hbase.util.RegionSplitter.SplitAlgorithm
-
In HBase, the last row is represented by an empty byte array.
- setFirstRow(String) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.UniformSplit
- setFixAssignments(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.Fix inconsistencies found by fsck.
- setFixEmptyMetaCells(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- setFixHdfsHoles(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- setFixHdfsOrphans(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- setFixHdfsOverlaps(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- setFixHFileLinks(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- setFixMeta(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- setFixReferenceFiles(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- setFixReplication(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.Set replication fix mode.
- setFixSplitParents(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- setFixTableOrphans(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- setFixVersionFile(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- setFloat(String, float) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
- setFlushPolicyClassName(String) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
- setFlushSizeLowerBounds(HRegion) - Method in class org.apache.hadoop.hbase.regionserver.FlushLargeStoresPolicy
- setForceExclusive() - Static method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.Set exclusive mode.
- setForegroundColor(Color) - Method in class org.apache.hadoop.hbase.hbtop.terminal.Attributes
- setFoundKV(boolean) - Method in class org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
-
Set or clear the indication if the first KV has been found.
- setFsDefault(Configuration, String) - Static method in class org.apache.hadoop.hbase.util.CommonFSUtils
- setFsDefault(Configuration, Path) - Static method in class org.apache.hadoop.hbase.util.CommonFSUtils
- setFsReadTime(long) - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord.OnlineLogRecordBuilder
- setGauge(String, long) - Method in interface org.apache.hadoop.hbase.metrics.BaseSource
-
Set a gauge to a specific value.
- setGauge(String, long) - Method in class org.apache.hadoop.hbase.metrics.BaseSourceImpl
-
Set a single gauge to a value.
- setGlobalMemStoreLimit(long) - Method in interface org.apache.hadoop.hbase.regionserver.FlushRequester
-
Sets the global memstore limit to a new size.
- setGlobalMemStoreLimit(long) - Method in class org.apache.hadoop.hbase.regionserver.MemStoreFlusher
-
Sets the global memstore limit to a new size.
- setGroups(Groups) - Static method in class org.apache.hadoop.hbase.security.UserProvider
- setHBaseCluster(HBaseCluster) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- setHBaseVersion(String) - Method in class org.apache.hadoop.hbase.ClusterMetricsBuilder
- setHbckChoreForTesting(HbckChore) - Method in class org.apache.hadoop.hbase.master.HMaster
-
Used for testing only to set Mock objects.
- setHdfsEntry(HbckRegionInfo.HdfsEntry) - Method in class org.apache.hadoop.hbase.util.HbckRegionInfo
- setHeaders(Header[]) - Method in class org.apache.hadoop.hbase.rest.client.Response
- setHFileCorruptionChecker(HFileCorruptionChecker) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- setHLogTargetDir(String) - Method in class org.apache.hadoop.hbase.backup.BackupInfo
- setHoles(int) - Method in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
-
Set the number of holes.
- setHoles(int) - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManagerSourceImpl
- setHTable(Table) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
- setHTable(Table) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
- setHTable(Table) - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReaderImpl
-
Sets the HBase table.
- setId(String) - Method in class org.apache.hadoop.hbase.client.Append
- setId(String) - Method in class org.apache.hadoop.hbase.client.Delete
- setId(String) - Method in class org.apache.hadoop.hbase.client.Get
- setId(String) - Method in class org.apache.hadoop.hbase.client.ImmutableScan
- setId(String) - Method in class org.apache.hadoop.hbase.client.Increment
- setId(String) - Method in class org.apache.hadoop.hbase.client.OperationWithAttributes
-
This method allows you to set an identifier on an operation.
- setId(String) - Method in class org.apache.hadoop.hbase.client.Put
- setId(String) - Method in class org.apache.hadoop.hbase.client.Scan
- setIfUnset(String, String) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
- setIgnoreDeleteForTesting(boolean) - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
-
Temporary function that is used by unit tests only
- setIgnoreNonceConflicts(boolean) - Method in class org.apache.hadoop.hbase.util.MultiThreadedUpdater
- setIgnorePreCheckPermission(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- setIgnoreRegionsInTransition(boolean) - Method in class org.apache.hadoop.hbase.client.BalanceRequest.Builder
-
Updates BalancerRequest to run the balancer even if there are regions in transition.
- setIncludesMvcc(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
- setIncludesTags(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
- setInconsistentRegions(int) - Method in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
-
Set the number of inconsistent regions.
- setInconsistentRegions(int) - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManagerSourceImpl
- setIncrBackupFileList(List<String>) - Method in class org.apache.hadoop.hbase.backup.BackupInfo
- setIncrTimestampMap(Map<TableName, Map<String, Long>>) - Method in class org.apache.hadoop.hbase.backup.BackupInfo
-
Set the new region server log timestamps after distributed log roll
- setIndexBlockEncoding(IndexBlockEncoding) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
- setInfoPort(int) - Method in class org.apache.hadoop.hbase.master.ActiveMasterManager
- setInfoServerPort(int) - Method in class org.apache.hadoop.hbase.ServerMetricsBuilder
- setInitialFunctionCosts(String) - Method in class org.apache.hadoop.hbase.client.BalancerDecision.Builder
- setInitialized(boolean) - Method in class org.apache.hadoop.hbase.master.HMaster
- setInitTotalCost(double) - Method in class org.apache.hadoop.hbase.client.BalancerDecision.Builder
- setInMemory(boolean) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
- setInMemoryCompaction(MemoryCompactionPolicy) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
- setInMemoryCompactionCompleted() - Method in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
- setInMemoryCompactionFlag() - Method in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
- setInMemoryFlushed() - Method in class org.apache.hadoop.hbase.regionserver.MutableSegment
- setInput(Configuration, String, Path) - Static method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl
-
Configures the job to use TableSnapshotInputFormat to read from a snapshot.
- setInput(Configuration, String, Path, RegionSplitter.SplitAlgorithm, int) - Static method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl
-
Configures the job to use TableSnapshotInputFormat to read from a snapshot.
- setInput(Configuration, Map<String, Collection<Scan>>, Path) - Static method in class org.apache.hadoop.hbase.mapred.MultiTableSnapshotInputFormat
- setInput(Configuration, Map<String, Collection<Scan>>, Path) - Static method in class org.apache.hadoop.hbase.mapreduce.MultiTableSnapshotInputFormat
- setInput(Configuration, Map<String, Collection<Scan>>, Path) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableSnapshotInputFormatImpl
-
Configure conf to read from snapshotScans, with snapshots restored to a subdirectory of restoreDir.
- setInput(JobConf, String, Path) - Static method in class org.apache.hadoop.hbase.mapred.TableSnapshotInputFormat
-
Configures the job to use TableSnapshotInputFormat to read from a snapshot.
- setInput(JobConf, String, Path, RegionSplitter.SplitAlgorithm, int) - Static method in class org.apache.hadoop.hbase.mapred.TableSnapshotInputFormat
-
Configures the job to use TableSnapshotInputFormat to read from a snapshot.
- setInput(Job, String, Path) - Static method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormat
-
Configures the job to use TableSnapshotInputFormat to read from a snapshot.
- setInput(Job, String, Path, RegionSplitter.SplitAlgorithm, int) - Static method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormat
-
Configures the job to use TableSnapshotInputFormat to read from a snapshot.
- setInputColumns(byte[][]) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
- setInputColumns(byte[][]) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
- setInputColumns(byte[][]) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
- setInt(String, int) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
- setIsolationLevel(IsolationLevel) - Method in class org.apache.hadoop.hbase.client.Get
- setIsolationLevel(IsolationLevel) - Method in class org.apache.hadoop.hbase.client.ImmutableScan
- setIsolationLevel(IsolationLevel) - Method in class org.apache.hadoop.hbase.client.Query
-
Set the isolation level for this query.
- setIsolationLevel(IsolationLevel) - Method in class org.apache.hadoop.hbase.client.Scan
- setIv(byte[]) - Method in class org.apache.hadoop.hbase.io.crypto.aes.AESDecryptor
- setIv(byte[]) - Method in class org.apache.hadoop.hbase.io.crypto.aes.AESEncryptor
- setIv(byte[]) - Method in class org.apache.hadoop.hbase.io.crypto.aes.CommonsCryptoAESDecryptor
- setIv(byte[]) - Method in class org.apache.hadoop.hbase.io.crypto.aes.CommonsCryptoAESEncryptor
- setIv(byte[]) - Method in interface org.apache.hadoop.hbase.io.crypto.Decryptor
-
Set the initialization vector
- setIv(byte[]) - Method in interface org.apache.hadoop.hbase.io.crypto.Encryptor
-
Set the initialization vector
- setJarPath(String) - Method in class org.apache.hadoop.hbase.client.CoprocessorDescriptorBuilder
- setJitter(float) - Method in class org.apache.hadoop.hbase.util.RetryCounter.RetryConfig
- setKeepDeletedCells(KeepDeletedCells) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
- setKeepDeletedCells(KeepDeletedCells) - Method in class org.apache.hadoop.hbase.regionserver.CustomizedScanInfoBuilder
- setKeepDeletedCells(KeepDeletedCells) - Method in interface org.apache.hadoop.hbase.regionserver.ScanOptions
- setKeepProgress(boolean) - Method in class org.apache.hadoop.hbase.regionserver.ScannerContext.Builder
- setKerberosNameRulesKey(String) - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
- setKey(byte[]) - Method in class org.apache.hadoop.hbase.io.crypto.Encryption.Context
- setKey(byte[], int, int) - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
-
A setter that helps to avoid object creation every time and whenever there is a need to create new KeyOnlyKeyValue.
- setKey(ByteBuffer, int, int) - Method in class org.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValue
-
A setter that helps to avoid object creation every time and whenever there is a need to create new OffheapKeyOnlyKeyValue.
- setKey(ByteBuffer, int, int, short) - Method in class org.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValue
-
A setter that helps to avoid object creation every time and whenever there is a need to create new OffheapKeyOnlyKeyValue.
- setKey(Key) - Method in class org.apache.hadoop.hbase.io.crypto.aes.AESDecryptor
- setKey(Key) - Method in class org.apache.hadoop.hbase.io.crypto.aes.AESEncryptor
- setKey(Key) - Method in class org.apache.hadoop.hbase.io.crypto.aes.CommonsCryptoAESDecryptor
- setKey(Key) - Method in class org.apache.hadoop.hbase.io.crypto.aes.CommonsCryptoAESEncryptor
- setKey(Key) - Method in class org.apache.hadoop.hbase.io.crypto.Context
- setKey(Key) - Method in interface org.apache.hadoop.hbase.io.crypto.Decryptor
-
Set the secret key
- setKey(Key) - Method in class org.apache.hadoop.hbase.io.crypto.Encryption.Context
- setKey(Key) - Method in interface org.apache.hadoop.hbase.io.crypto.Encryptor
-
Set the secret key
- setKeytabConfKey(String) - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
- setKeyValues(Configuration, String, Collection<Map.Entry<String, String>>) - Static method in class org.apache.hadoop.hbase.util.ConfigurationUtil
-
Store a collection of Map.Entry's in conf, with each entry separated by ',' and key values delimited by
ConfigurationUtil.KVP_DELIMITER
- setKeyValues(Configuration, String, Collection<Map.Entry<String, String>>, char) - Static method in class org.apache.hadoop.hbase.util.ConfigurationUtil
-
Store a collection of Map.Entry's in conf, with each entry separated by ',' and key values delimited by delimiter.
- setKeyWindow(int) - Method in class org.apache.hadoop.hbase.util.MultiThreadedReader
- setLastDataBlockOffset(long) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
- setLastMajorCompactionTimestamp(long) - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder
- setLastReportTimestamp(long) - Method in class org.apache.hadoop.hbase.ServerMetricsBuilder
- setLastRow(byte[]) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.NumberStringSplit
- setLastRow(byte[]) - Method in interface org.apache.hadoop.hbase.util.RegionSplitter.SplitAlgorithm
-
Set the last row
- setLastRow(byte[]) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.UniformSplit
- setLastRow(String) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.NumberStringSplit
- setLastRow(String) - Method in interface org.apache.hadoop.hbase.util.RegionSplitter.SplitAlgorithm
-
In HBase, the last row is represented by an empty byte array.
- setLastRow(String) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.UniformSplit
- setLastSequenceIds(String, Map<String, Long>) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueueStorage
-
Set the max sequence id of a bunch of regions for a given peer.
- setLastSequenceIds(String, Map<String, Long>) - Method in class org.apache.hadoop.hbase.replication.TableReplicationQueueStorage
- setLatestVersionOnly(boolean) - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
Set whether only the latest version of the column value should be compared.
- setLength(int) - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
- setLength(int) - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
-
Update the length of this range.
- setLength(int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Update the length of this range.
- setLength(int) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
- setLength(int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
-
Update the length of this range.
- setLimit(int) - Method in class org.apache.hadoop.hbase.client.ImmutableScan
- setLimit(int) - Method in class org.apache.hadoop.hbase.client.LogQueryFilter
-
Deprecated.
- setLimit(int) - Method in class org.apache.hadoop.hbase.client.Scan
-
Set the limit of rows for this scan.
- setLimit(int) - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
- setLimit(int) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
Limits the byte range upto a specified value.
- setLimit(int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
- setLiveServerMetrics(Map<ServerName, ServerMetrics>) - Method in class org.apache.hadoop.hbase.ClusterMetricsBuilder
- setLoadColumnFamiliesOnDemand(boolean) - Method in class org.apache.hadoop.hbase.client.Get
- setLoadColumnFamiliesOnDemand(boolean) - Method in class org.apache.hadoop.hbase.client.ImmutableScan
- setLoadColumnFamiliesOnDemand(boolean) - Method in class org.apache.hadoop.hbase.client.Query
-
Set the value indicating whether loading CFs on demand should be allowed (cluster default is false).
- setLoadColumnFamiliesOnDemand(boolean) - Method in class org.apache.hadoop.hbase.client.Scan
- setLoadOnOpenOffset(long) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
- setLocations(Path, Path...) - Method in class org.apache.hadoop.hbase.io.FileLink
-
NOTE: This method must be used only in the constructor! It creates a List with the specified locations for the link.
- setLogDir(String) - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
- setLoggingUncaughtExceptionHandler(Thread) - Static method in class org.apache.hadoop.hbase.util.Threads
-
Sets an UncaughtExceptionHandler for the thread which logs the Exception stack if the thread dies.
- setLogLevel(String, String) - Static method in class org.apache.hadoop.hbase.logging.Log4jUtils
- setLong(String, long) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
- setMajorCompactionCompressionType(Compression.Algorithm) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
- setMapperClass(Job, Class<? extends Mapper<ImmutableBytesWritable, Result, K2, V2>>) - Static method in class org.apache.hadoop.hbase.mapreduce.MultithreadedTableMapper
-
Set the application's mapper class.
- setMasterAddress(ZKWatcher, String, ServerName, int) - Static method in class org.apache.hadoop.hbase.zookeeper.MasterAddressTracker
-
Set master address into the
master
znode or into the backup subdirectory of backup masters; switch off the passed inznode
path. - setMasterCoprocessorNames(List<String>) - Method in class org.apache.hadoop.hbase.ClusterMetricsBuilder
- setMasterInfoPort(int) - Method in class org.apache.hadoop.hbase.ClusterMetricsBuilder
- setMasterName(ServerName) - Method in class org.apache.hadoop.hbase.ClusterMetricsBuilder
- setMasterServices(MasterServices) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupBasedLoadBalancer
- setMasterTasks(List<ServerTask>) - Method in class org.apache.hadoop.hbase.ClusterMetricsBuilder
- setMax(long) - Method in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker.NonSyncTimeRangeTracker
- setMax(long) - Method in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker
- setMax(long) - Method in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker.SyncTimeRangeTracker
- setMaxAttempts(int) - Method in interface org.apache.hadoop.hbase.client.AsyncAdminBuilder
-
Set the max attempt times for an admin operation.
- setMaxAttempts(int) - Method in interface org.apache.hadoop.hbase.client.AsyncBufferedMutatorBuilder
-
Set the max attempt times for an operation.
- setMaxAttempts(int) - Method in interface org.apache.hadoop.hbase.client.AsyncTableBuilder
-
Set the max attempt times for an operation.
- setMaxAttempts(int) - Method in class org.apache.hadoop.hbase.util.RetryCounter.RetryConfig
- setMaxChunkSize(int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexWriter
- setMaxCompactedStoreFileRefCount(int) - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder
- setMaxErrors(int) - Method in class org.apache.hadoop.hbase.util.MultiThreadedReader
- setMaxFileSize(long) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
- setMaxFileSize(String) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
- setMaxHeapSize(Size) - Method in class org.apache.hadoop.hbase.ServerMetricsBuilder
- setMaxKeyValueSize(int) - Method in interface org.apache.hadoop.hbase.client.AsyncBufferedMutatorBuilder
-
Override the maximum key-value size specified by the provided
AsyncConnection
'sConfiguration
instance, via the configuration keyhbase.client.keyvalue.maxsize
. - setMaxMerge(int) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- setMaxOverlapsToSideline(int) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- setMaxPoolSize(int) - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
- setMaxPoolSize(int) - Method in interface org.apache.hadoop.hbase.thrift.IncrementCoalescerMBean
- setMaxQueueSize(int) - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
- setMaxQueueSize(int) - Method in interface org.apache.hadoop.hbase.thrift.IncrementCoalescerMBean
- setMaxRecoveryErrorCount(OutputStream, int) - Static method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Set maxRecoveryErrorCount in DFSClient.
- setMaxResultSize(long) - Method in class org.apache.hadoop.hbase.client.ImmutableScan
- setMaxResultSize(long) - Method in class org.apache.hadoop.hbase.client.Scan
-
Set the maximum result size.
- setMaxResultsPerColumnFamily(int) - Method in class org.apache.hadoop.hbase.client.Get
-
Set the maximum number of values to return per row per Column Family
- setMaxResultsPerColumnFamily(int) - Method in class org.apache.hadoop.hbase.client.ImmutableScan
- setMaxResultsPerColumnFamily(int) - Method in class org.apache.hadoop.hbase.client.Scan
-
Set the maximum number of values to return per row per Column Family
- setMaxRetries(int) - Method in interface org.apache.hadoop.hbase.client.AsyncAdminBuilder
-
Set the max retry times for an admin operation.
- setMaxRetries(int) - Method in interface org.apache.hadoop.hbase.client.AsyncBufferedMutatorBuilder
-
Set the max retry times for an operation.
- setMaxRetries(int) - Method in interface org.apache.hadoop.hbase.client.AsyncTableBuilder
-
Set the max retry times for an operation.
- setMaxSize(long) - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
- setMaxSize(long) - Method in class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache
- setMaxSize(long) - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
- setMaxSize(long) - Method in interface org.apache.hadoop.hbase.io.hfile.ResizableBlockCache
-
Sets the max heap size that can be used by the BlockCache.
- setMaxSize(long) - Method in class org.apache.hadoop.hbase.io.hfile.TinyLfuBlockCache
- setMaxSleepTime(long) - Method in class org.apache.hadoop.hbase.util.RetryCounter.RetryConfig
- setMaxThroughput(double) - Method in class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareThroughputController
- setMaxValues(int) - Method in class org.apache.hadoop.hbase.rest.RowSpec
- setMaxVersions(int) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
- setMaxVersions(int) - Method in class org.apache.hadoop.hbase.regionserver.CustomizedScanInfoBuilder
- setMaxVersions(int) - Method in interface org.apache.hadoop.hbase.regionserver.ScanOptions
- setMaxVersions(int) - Method in class org.apache.hadoop.hbase.rest.RowSpec
- setMemStoreFlushSize(long) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
- setMemStoreFlushSize(String) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
- setMemStoreSize(float) - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerResult
- setMemStoreSize(Size) - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder
- setMerged(boolean) - Method in class org.apache.hadoop.hbase.util.HbckRegionInfo
- setMergeEnabled(boolean) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
- setMetaBlockIndexReader(HFileBlockIndex.ByteArrayKeyBlockIndexReader) - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
- setMetaBlockIndexReader(HFileBlockIndex.ByteArrayKeyBlockIndexReader) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
- setMetaEntry(HbckRegionInfo.MetaEntry) - Method in class org.apache.hadoop.hbase.util.HbckRegionInfo
- setMetaIndexCount(int) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
- setMetaLocation(ZKWatcher, ServerName, int, RegionState.State) - Static method in class org.apache.hadoop.hbase.zookeeper.MetaTableLocator
-
Sets the location of
hbase:meta
in ZooKeeper to the specified server address. - setMetaLocation(ZKWatcher, ServerName, RegionState.State) - Static method in class org.apache.hadoop.hbase.zookeeper.MetaTableLocator
-
Sets the location of
hbase:meta
in ZooKeeper to the specified server address. - setMethodDescriptor(Descriptors.MethodDescriptor) - Method in class org.apache.hadoop.hbase.client.trace.IpcClientSpanBuilder
- setMethodName(String) - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord.OnlineLogRecordBuilder
- setMetricsSource(JvmPauseMonitorSource) - Method in class org.apache.hadoop.hbase.util.JvmPauseMonitor
- setMigrationDone() - Method in class org.apache.hadoop.hbase.master.TableNamespaceManager
- setMin(long) - Method in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker.NonSyncTimeRangeTracker
- setMin(long) - Method in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker
- setMin(long) - Method in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker.SyncTimeRangeTracker
- setMinIndexNumEntries(int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexWriter
- setMinorCompactionCompressionType(Compression.Algorithm) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
- setMinVersions(int) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
- setMinVersions(int) - Method in class org.apache.hadoop.hbase.regionserver.CustomizedScanInfoBuilder
- setMinVersions(int) - Method in interface org.apache.hadoop.hbase.regionserver.ScanOptions
- setMobCompactPartitionPolicy(MobCompactPartitionPolicy) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
- setMobEnabled(boolean) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
- setMobFileCache(MobFileCache) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Only used for unit test which doesn't start region server.
- setMobThreshold(long) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
- setMovesCalculated(int) - Method in class org.apache.hadoop.hbase.client.BalanceResponse.Builder
-
Set how many moves were calculated by the balancer.
- setMovesExecuted(int) - Method in class org.apache.hadoop.hbase.client.BalanceResponse.Builder
-
Set how many of the calculated moves were actually executed by the balancer.
- setMultiGetBatchSize(int) - Method in class org.apache.hadoop.hbase.util.MultiThreadedReader
- setMultiGetsCount(int) - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord.OnlineLogRecordBuilder
- setMultiMutationsCount(int) - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord.OnlineLogRecordBuilder
- setMultiPut(boolean) - Method in class org.apache.hadoop.hbase.util.MultiThreadedWriter
-
Use multi-puts vs.
- setMultiServiceCalls(int) - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord.OnlineLogRecordBuilder
- setMvccReadPoint(Scan, long) - Static method in class org.apache.hadoop.hbase.client.ClientInternalHelper
- setName(String) - Method in class org.apache.hadoop.hbase.client.trace.ConnectionSpanBuilder
- setName(String) - Method in class org.apache.hadoop.hbase.client.trace.TableSpanBuilder
- setName(String) - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
-
Deprecated.Since 0.99.0. Use
HttpServer.Builder.setAppDir(String)
instead. - setName(String) - Method in class org.apache.hadoop.hbase.server.trace.IpcServerSpanBuilder
- setNamedQueueEvent(int) - Method in class org.apache.hadoop.hbase.namequeues.request.NamedQueueGetRequest
- setNamedQueueEvent(int) - Method in class org.apache.hadoop.hbase.namequeues.response.NamedQueueGetResponse
- setNamedQueueRecorder(NamedQueueRecorder) - Method in class org.apache.hadoop.hbase.ipc.RpcServer
- setNamedQueueRecorder(NamedQueueRecorder) - Method in interface org.apache.hadoop.hbase.ipc.RpcServerInterface
-
Set Online SlowLog Provider
- setNamespaceFilter(String) - Method in class org.apache.hadoop.hbase.quotas.QuotaFilter
-
Set the namespace filter regex
- setNamespaceQuota(String, MasterProtos.SetQuotaRequest) - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
- setNamespaceQuota(NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
- setNamespaces(Set<String>) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeerConfigBuilder
-
Sets a unique collection of HBase namespaces that should be replicated to this peer.
- setNeedCursorResult(boolean) - Method in class org.apache.hadoop.hbase.client.ImmutableScan
- setNeedCursorResult(boolean) - Method in class org.apache.hadoop.hbase.client.Scan
-
When the server is slow or we scan a table with many deleted data or we use a sparse filter, the server will response heartbeat to prevent timeout.
- setNewSyncReplicationState(SyncReplicationState) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerImpl
- setNewVersionBehavior(boolean) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
- setNextRefillTime(long) - Method in class org.apache.hadoop.hbase.quotas.AverageIntervalRateLimiter
- setNextRefillTime(long) - Method in class org.apache.hadoop.hbase.quotas.FixedIntervalRateLimiter
- setNextRefillTime(long) - Method in class org.apache.hadoop.hbase.quotas.RateLimiter
- setNoChecksumVerify(boolean) - Method in class org.apache.hadoop.hbase.backup.BackupInfo
- setNonce(long) - Method in class org.apache.hadoop.hbase.client.Action
- setNonSeekedState() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.EncodedScanner
- setNonSeekedState() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
- setNormalizationEnabled(boolean) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
- setNormalizerRunning(RpcController, MasterProtos.SetNormalizerRunningRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- setNormalizerTargetRegionCount(int) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
- setNormalizerTargetRegionSize(long) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
- setNoStripeMetadata() - Method in class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter
- setNumActionsPerServer(int) - Method in class org.apache.hadoop.hbase.client.MetricsConnection.CallStats
- setNumberOfThreads(Job, int) - Static method in class org.apache.hadoop.hbase.mapreduce.MultithreadedTableMapper
-
Set the number of threads in the pool for running maps.
- setNumDataIndexLevels(int) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
- setNumMapTasks(String, JobConf) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
-
Sets the number of map tasks for the given job configuration to the number of regions the given table has.
- setNumNamespacesInSpaceQuotaViolation(long) - Method in class org.apache.hadoop.hbase.master.MetricsMaster
-
Sets the number of namespaces in violation of a space quota.
- setNumReduceTasks(String, JobConf) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
-
Sets the number of reduce tasks for the given job configuration to the number of regions the given table has.
- setNumReduceTasks(String, Job) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Sets the number of reduce tasks for the given job configuration to the number of regions the given table has.
- setNumRegions(int) - Method in class org.apache.hadoop.hbase.util.compaction.MajorCompactor
- setNumRegionSizeReports(long) - Method in class org.apache.hadoop.hbase.master.MetricsMaster
-
Sets the number of region size reports the master currently has in memory.
- setNumServers(int) - Method in class org.apache.hadoop.hbase.util.compaction.MajorCompactor
- setNumSpaceQuotas(long) - Method in class org.apache.hadoop.hbase.master.MetricsMaster
-
Sets the number of space quotas defined.
- setNumTableInSpaceQuotaViolation(long) - Method in class org.apache.hadoop.hbase.master.MetricsMaster
-
Sets the number of table in violation of a space quota.
- setOffheapMemStore(boolean) - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerContext
- setOffline(boolean) - Method in class org.apache.hadoop.hbase.client.RegionInfoBuilder
-
Deprecated.
- setOffset(int) - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
- setOffset(int) - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
-
Update the beginning of this range.
- setOffset(int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Update the beginning of this range.
- setOffset(int) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
- setOffset(int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
-
Update the beginning of this range.
- setOffset(ReplicationQueueId, String, ReplicationGroupOffset, Map<String, Long>) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueueStorage
-
Set the current offset for a specific WAL group in a given queue.
- setOffset(ReplicationQueueId, String, ReplicationGroupOffset, Map<String, Long>) - Method in class org.apache.hadoop.hbase.replication.TableReplicationQueueStorage
- setOneRowLimit() - Method in class org.apache.hadoop.hbase.client.ImmutableScan
- setOneRowLimit() - Method in class org.apache.hadoop.hbase.client.Scan
-
Call this when you only want to get one row.
- setOpenRegions(int) - Method in class org.apache.hadoop.hbase.client.RegionStatesCount.RegionStatesCountBuilder
- setOperation(Collection<? extends Row>) - Method in class org.apache.hadoop.hbase.client.trace.TableOperationSpanBuilder
- setOperation(Row) - Method in class org.apache.hadoop.hbase.client.trace.TableOperationSpanBuilder
- setOperation(Scan) - Method in class org.apache.hadoop.hbase.client.trace.TableOperationSpanBuilder
- setOperation(HBaseSemanticAttributes.Operation) - Method in class org.apache.hadoop.hbase.client.trace.TableOperationSpanBuilder
- setOperationStatus(int, OperationStatus) - Method in class org.apache.hadoop.hbase.regionserver.MiniBatchOperationInProgress
-
Sets the status code for the operation(Mutation) at the specified position.
- setOperationTimeout(int) - Method in interface org.apache.hadoop.hbase.client.BufferedMutator
-
Deprecated.Since 3.0.0, will be removed in 4.0.0. Please set this through the
BufferedMutatorParams
. - setOperationTimeout(int) - Method in interface org.apache.hadoop.hbase.client.TableBuilder
-
Set timeout for a whole operation such as get, put or delete.
- setOperationTimeout(long, TimeUnit) - Method in interface org.apache.hadoop.hbase.client.AsyncAdminBuilder
-
Set timeout for a whole admin operation.
- setOperationTimeout(long, TimeUnit) - Method in interface org.apache.hadoop.hbase.client.AsyncBufferedMutatorBuilder
-
Set timeout for the background flush operation.
- setOperationTimeout(long, TimeUnit) - Method in interface org.apache.hadoop.hbase.client.AsyncTableBuilder
-
Set timeout for a whole operation such as get, put or delete.
- setoPsShipped(long) - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSource.ReplicationLoadSourceBuilder
- setOrigLogSeqNum(long) - Method in class org.apache.hadoop.hbase.wal.WALKeyImpl
-
Used to set original sequenceId for WALKeyImpl during WAL replay
- setOrphanRegionsOnFs(int) - Method in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
-
Set the number of orphan regions on FS.
- setOrphanRegionsOnFs(int) - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManagerSourceImpl
- setOrphanRegionsOnRs(int) - Method in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
-
Set the number of orphan regions on RS.
- setOrphanRegionsOnRs(int) - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManagerSourceImpl
- setOutputOnlyRowKey() - Method in class org.apache.hadoop.hbase.wal.WALPrettyPrinter
-
Option to print the row key only in case you just need the row keys from the WAL
- setOverlaps(int) - Method in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
-
Set the number of overlaps.
- setOverlaps(int) - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManagerSourceImpl
- setParam(String) - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord.OnlineLogRecordBuilder
- setPathSpec(String[]) - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
- setPattern(String, Pattern) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
- setPeerConfig(ReplicationPeerConfig) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerImpl
- setPeerID(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSource.ReplicationLoadSourceBuilder
- setPeerNewSyncReplicationState(String, SyncReplicationState) - Method in class org.apache.hadoop.hbase.replication.FSReplicationPeerStorage
- setPeerNewSyncReplicationState(String, SyncReplicationState) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeerStorage
-
Set the new sync replication state that we are going to transit to.
- setPeerNewSyncReplicationState(String, SyncReplicationState) - Method in class org.apache.hadoop.hbase.replication.ZKReplicationPeerStorage
- setPeerState(boolean) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerImpl
- setPeerState(String, boolean) - Method in class org.apache.hadoop.hbase.replication.FSReplicationPeerStorage
- setPeerState(String, boolean) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeerStorage
-
Set the state of peer,
true
toENABLED
, otherwise toDISABLED
. - setPeerState(String, boolean) - Method in class org.apache.hadoop.hbase.replication.ZKReplicationPeerStorage
- setPhase(BackupInfo.BackupPhase) - Method in class org.apache.hadoop.hbase.backup.BackupInfo
- setPolicy(HttpConfig.Policy) - Method in class org.apache.hadoop.hbase.http.HttpConfig
- setPort(int) - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
-
Deprecated.Since 0.99.0. Use
HttpServer.Builder.addEndpoint(URI)
instead. - setPosition(int) - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
- setPosition(int) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
Update the
position
index. - setPosition(long) - Method in class org.apache.hadoop.hbase.wal.WALPrettyPrinter
-
sets the position to start seeking the WAL file initial position to start seeking the given WAL file
- setPrefetchBlocksOnOpen(boolean) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
- setPrintStreams(PrintStream, PrintStream) - Method in class org.apache.hadoop.hbase.io.hfile.HFilePrettyPrinter
- setPriority(int) - Method in class org.apache.hadoop.hbase.client.Append
- setPriority(int) - Method in class org.apache.hadoop.hbase.client.CoprocessorDescriptorBuilder
- setPriority(int) - Method in class org.apache.hadoop.hbase.client.Delete
- setPriority(int) - Method in class org.apache.hadoop.hbase.client.Get
- setPriority(int) - Method in class org.apache.hadoop.hbase.client.ImmutableScan
- setPriority(int) - Method in class org.apache.hadoop.hbase.client.Increment
- setPriority(int) - Method in class org.apache.hadoop.hbase.client.OperationWithAttributes
- setPriority(int) - Method in class org.apache.hadoop.hbase.client.Put
- setPriority(int) - Method in class org.apache.hadoop.hbase.client.Scan
- setPriority(int) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
- setPriority(int) - Method in class org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
- setPriority(int) - Method in interface org.apache.hadoop.hbase.ipc.HBaseRpcController
-
Set the priority for this operation.
- setPriority(int) - Method in class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
- setPriority(TableName) - Method in class org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
- setPriority(TableName) - Method in interface org.apache.hadoop.hbase.ipc.HBaseRpcController
-
Set the priority for this operation.
- setPriority(TableName) - Method in class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
- setProcessed(boolean) - Method in class org.apache.hadoop.hbase.client.SingleResponse.Entry
- setProcessingTime(int) - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord.OnlineLogRecordBuilder
- setProgress(int) - Method in class org.apache.hadoop.hbase.backup.BackupInfo
-
Set progress (0-100%)
- setProperties(Map<String, String>) - Method in class org.apache.hadoop.hbase.client.CoprocessorDescriptorBuilder
- setProperty(String, String) - Method in class org.apache.hadoop.hbase.client.CoprocessorDescriptorBuilder
- setQualifier(byte[]) - Method in interface org.apache.hadoop.hbase.CellBuilder
- setQualifier(byte[]) - Method in interface org.apache.hadoop.hbase.ExtendedCellBuilder
- setQualifier(byte[]) - Method in class org.apache.hadoop.hbase.ExtendedCellBuilderImpl
- setQualifier(byte[]) - Method in interface org.apache.hadoop.hbase.RawCellBuilder
- setQualifier(byte[], int, int) - Method in interface org.apache.hadoop.hbase.CellBuilder
- setQualifier(byte[], int, int) - Method in interface org.apache.hadoop.hbase.ExtendedCellBuilder
- setQualifier(byte[], int, int) - Method in class org.apache.hadoop.hbase.ExtendedCellBuilderImpl
- setQualifier(byte[], int, int) - Method in interface org.apache.hadoop.hbase.RawCellBuilder
- setQueueId(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSource.ReplicationLoadSourceBuilder
- setQueueTime(int) - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord.OnlineLogRecordBuilder
- setQuietMode(boolean) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
- setQuota(QuotaSettings) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Apply the new quota settings.
- setQuota(QuotaSettings) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Apply the new quota settings.
- setQuota(MasterProtos.SetQuotaRequest) - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
- setQuota(RpcController, MasterProtos.SetQuotaRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- setQuotas(String, QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.quotas.UserQuotaState
-
Add the quota information of the specified namespace.
- setQuotas(QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.quotas.QuotaState
-
Setup the global quota information.
- setQuotas(QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.quotas.UserQuotaState
- setQuotas(TableName, QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.quotas.UserQuotaState
-
Add the quota information of the specified table.
- setQuotaSnapshot(SpaceQuotaSnapshot) - Method in class org.apache.hadoop.hbase.quotas.policies.AbstractViolationPolicyEnforcement
- setRandomGeneratorForTest(Random) - Static method in class org.apache.hadoop.hbase.util.BloomFilterUtil
-
Sets a random generator to be used for look-ups instead of computing hashes.
- setRaw(boolean) - Method in class org.apache.hadoop.hbase.client.ImmutableScan
- setRaw(boolean) - Method in class org.apache.hadoop.hbase.client.Scan
-
Enable/disable "raw" mode for this scan.
- setReadahead(Long) - Method in class org.apache.hadoop.hbase.io.FileLink.FileLinkInputStream
- setReadOnly(boolean) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
- setReadRequestCount(long) - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder
- setReadRequestCount(long) - Method in class org.apache.hadoop.hbase.ServerMetricsBuilder
- setReadRpcTimeout(int) - Method in interface org.apache.hadoop.hbase.client.TableBuilder
-
Set timeout for each read(get, scan) rpc request.
- setReadRpcTimeout(long, TimeUnit) - Method in interface org.apache.hadoop.hbase.client.AsyncTableBuilder
-
Set timeout for each read(get, scan) rpc request.
- setReadsEnabled(boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
- setReadType(Scan.ReadType) - Method in class org.apache.hadoop.hbase.client.ImmutableScan
- setReadType(Scan.ReadType) - Method in class org.apache.hadoop.hbase.client.Scan
-
Set the read type for this scan.
- setReason(String) - Method in class org.apache.hadoop.hbase.client.BalancerRejection.Builder
- setRecovered(boolean) - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSource.ReplicationLoadSourceBuilder
- setRegionCachedInfo(Map<String, Integer>) - Method in class org.apache.hadoop.hbase.ServerMetricsBuilder
- setRegionCoprocessorHost(RegionCoprocessorHost) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
Sets the region coprocessor env.
- setRegionFilter(String) - Method in class org.apache.hadoop.hbase.wal.WALPrettyPrinter
-
sets the region by which output will be filtered when not null, serves as a filter; only log entries from this region will be printed
- setRegionId(long) - Method in class org.apache.hadoop.hbase.client.RegionInfoBuilder
- setRegionMemStoreReplication(boolean) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
- setRegionMetrics(List<RegionMetrics>) - Method in class org.apache.hadoop.hbase.ServerMetricsBuilder
- setRegionName(String) - Method in class org.apache.hadoop.hbase.client.LogQueryFilter
-
Deprecated.
- setRegionName(String) - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord.OnlineLogRecordBuilder
- setRegionPlans(List<String>) - Method in class org.apache.hadoop.hbase.client.BalancerDecision.Builder
- setRegionReplicaId(int) - Method in class org.apache.hadoop.hbase.util.MultiThreadedReader
- setRegionReplication(int) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
- setRegionServerFilter(String) - Method in class org.apache.hadoop.hbase.quotas.QuotaFilter
-
Set the region server filter regex
- setRegionServerGroup(String) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
- setRegionServerQuota(String, MasterProtos.SetQuotaRequest) - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
- setRegionServerServices(RegionServerServices) - Method in class org.apache.hadoop.hbase.quotas.policies.AbstractViolationPolicyEnforcement
- setRegionsInTransition(int) - Method in class org.apache.hadoop.hbase.client.RegionStatesCount.RegionStatesCountBuilder
- setRegionsInTransition(List<RegionState>) - Method in class org.apache.hadoop.hbase.ClusterMetricsBuilder
- setRegionSizeMB(Size) - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder
- setRegionSplitPolicyClassName(String) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
- setRegionStateInMeta(Map<String, RegionState.State>) - Method in class org.apache.hadoop.hbase.client.HBaseHbck
- setRegionStateInMeta(Map<String, RegionState.State>) - Method in interface org.apache.hadoop.hbase.client.Hbck
-
Update region state in Meta only.
- setRegionStateInMeta(RpcController, MasterProtos.SetRegionStateInMetaRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
Update state of the region in meta only.
- setRegionUsage(Map<RegionInfo, Long>) - Method in class org.apache.hadoop.hbase.quotas.NamespaceQuotaSnapshotStore
- setRegionUsage(Map<RegionInfo, Long>) - Method in interface org.apache.hadoop.hbase.quotas.QuotaSnapshotStore
-
Updates
this
with the latest snapshot of filesystem use by region. - setRegionUsage(Map<RegionInfo, Long>) - Method in class org.apache.hadoop.hbase.quotas.TableQuotaSnapshotStore
- setRemoteAddress(Address) - Method in class org.apache.hadoop.hbase.client.trace.IpcClientSpanBuilder
- setRemoteWALDir(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeerConfigBuilder
-
Set the remote peer cluster's wal directory.
- setRemoveParents(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- setReplicaId(int) - Method in class org.apache.hadoop.hbase.client.Get
- setReplicaId(int) - Method in class org.apache.hadoop.hbase.client.ImmutableScan
- setReplicaId(int) - Method in class org.apache.hadoop.hbase.client.Query
-
Specify region replica id where Query will fetch data from.
- setReplicaId(int) - Method in class org.apache.hadoop.hbase.client.RegionInfoBuilder
- setReplicaId(int) - Method in class org.apache.hadoop.hbase.client.Scan
- setReplicas(Admin, TableName, int) - Static method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Set the number of Region replicas.
- setReplicateAllUserTables(boolean) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeerConfigBuilder
-
Configures HBase to replicate all user tables (not system tables) to the peer.
- setReplicationEndpointImpl(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeerConfigBuilder
-
Sets the ReplicationEndpoint plugin class for this peer.
- setReplicationLag(long) - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSource.ReplicationLoadSourceBuilder
- setReplicationLoadSink(ReplicationLoadSink) - Method in class org.apache.hadoop.hbase.ServerMetricsBuilder
- setReplicationLoadSources(List<ReplicationLoadSource>) - Method in class org.apache.hadoop.hbase.ServerMetricsBuilder
- setReplicationScope(int) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
Sets replication scope all & only the columns already in the builder.
- setReportTimestamp(long) - Method in class org.apache.hadoop.hbase.ServerMetricsBuilder
- setRequestAttribute(String, byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncBufferedMutatorBuilder
-
Set a rpc request attribute.
- setRequestAttribute(String, byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncTableBuilder
-
Set a request attribute
- setRequestAttribute(String, byte[]) - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
- setRequestAttribute(String, byte[]) - Method in interface org.apache.hadoop.hbase.client.TableBuilder
-
Set a request attribute
- setRequestAttributes(Map<String, byte[]>) - Method in interface org.apache.hadoop.hbase.client.AsyncBufferedMutatorBuilder
-
Set multiple rpc request attributes.
- setRequestAttributes(Map<String, byte[]>) - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord.OnlineLogRecordBuilder
- setRequestAttributes(Map<String, byte[]>) - Method in class org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
- setRequestAttributes(Map<String, byte[]>) - Method in interface org.apache.hadoop.hbase.ipc.HBaseRpcController
-
Set the map of request attributes
- setRequestAttributes(Map<String, byte[]>) - Method in class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
- setRequestCount(long) - Method in class org.apache.hadoop.hbase.ServerMetricsBuilder
- setRequestCountPerSecond(long) - Method in class org.apache.hadoop.hbase.ServerMetricsBuilder
- setRequestSizeBytes(long) - Method in class org.apache.hadoop.hbase.client.MetricsConnection.CallStats
- setResponse(Message, ExtendedCellScanner, Throwable, String) - Method in interface org.apache.hadoop.hbase.ipc.RpcCall
-
Set the response resulting from this RPC call.
- setResponse(Message, ExtendedCellScanner, Throwable, String) - Method in class org.apache.hadoop.hbase.ipc.ServerCall
- setResponseSize(long) - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord.OnlineLogRecordBuilder
- setResponseSizeBytes(long) - Method in class org.apache.hadoop.hbase.client.MetricsConnection.CallStats
- setRestoredRegion(boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
- setResult(Result) - Method in class org.apache.hadoop.hbase.client.SingleResponse.Entry
- setRetCode(int) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- setRetryPause(long, TimeUnit) - Method in interface org.apache.hadoop.hbase.client.AsyncAdminBuilder
-
Set the base pause time for retrying.
- setRetryPause(long, TimeUnit) - Method in interface org.apache.hadoop.hbase.client.AsyncBufferedMutatorBuilder
-
Set the base pause time for retrying.
- setRetryPause(long, TimeUnit) - Method in interface org.apache.hadoop.hbase.client.AsyncTableBuilder
-
Set the base pause time for retrying.
- setRetryPauseForCQTBE(long, TimeUnit) - Method in interface org.apache.hadoop.hbase.client.AsyncAdminBuilder
-
Deprecated.Since 2.5.0, will be removed in 4.0.0. Please use
AsyncAdminBuilder.setRetryPauseForServerOverloaded(long, TimeUnit)
instead. - setRetryPauseForCQTBE(long, TimeUnit) - Method in interface org.apache.hadoop.hbase.client.AsyncTableBuilder
-
Deprecated.Since 2.5.0, will be removed in 4.0.0. Please use
AsyncTableBuilder.setRetryPauseForServerOverloaded(long, TimeUnit)
instead. - setRetryPauseForServerOverloaded(long, TimeUnit) - Method in interface org.apache.hadoop.hbase.client.AsyncAdminBuilder
-
Set the base pause time for retrying when
HBaseServerException.isServerOverloaded()
. - setRetryPauseForServerOverloaded(long, TimeUnit) - Method in interface org.apache.hadoop.hbase.client.AsyncTableBuilder
-
Set the base pause time for retrying when
HBaseServerException.isServerOverloaded()
. - setReturnResults(boolean) - Method in class org.apache.hadoop.hbase.client.Append
-
True (default) if the append operation should return the results.
- setReturnResults(boolean) - Method in class org.apache.hadoop.hbase.client.Increment
- setReturnResults(boolean) - Method in class org.apache.hadoop.hbase.client.Mutation
- setReverse(boolean) - Method in class org.apache.hadoop.hbase.hbtop.terminal.Attributes
- setReversed(boolean) - Method in class org.apache.hadoop.hbase.client.ImmutableScan
- setReversed(boolean) - Method in class org.apache.hadoop.hbase.client.Scan
-
Set whether this scan is a reversed one
- setReversed(boolean) - Method in class org.apache.hadoop.hbase.filter.Filter
-
alter the reversed scan flag
- setReversed(boolean) - Method in class org.apache.hadoop.hbase.filter.FilterList
- setReversed(boolean) - Method in class org.apache.hadoop.hbase.filter.FilterListBase
- setRIT(int) - Method in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
-
Set the number of regions in transition.
- setRIT(int) - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManagerSourceImpl
- setRITCountOverThreshold(int) - Method in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
-
Set the count of the number of regions that have been in transition over the threshold time.
- setRITCountOverThreshold(int) - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManagerSourceImpl
- setRITOldestAge(long) - Method in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
-
Set the oldest region in transition.
- setRITOldestAge(long) - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManagerSourceImpl
- setRootDir(Configuration, Path) - Static method in class org.apache.hadoop.hbase.util.CommonFSUtils
- setRootLevel(String) - Static method in class org.apache.hadoop.hbase.logging.Log4jUtils
- setRow(byte[]) - Method in interface org.apache.hadoop.hbase.CellBuilder
- setRow(byte[]) - Method in interface org.apache.hadoop.hbase.ExtendedCellBuilder
- setRow(byte[]) - Method in class org.apache.hadoop.hbase.ExtendedCellBuilderImpl
- setRow(byte[]) - Method in interface org.apache.hadoop.hbase.RawCellBuilder
- setRow(byte[], int, int) - Method in interface org.apache.hadoop.hbase.CellBuilder
- setRow(byte[], int, int) - Method in interface org.apache.hadoop.hbase.ExtendedCellBuilder
- setRow(byte[], int, int) - Method in class org.apache.hadoop.hbase.ExtendedCellBuilderImpl
- setRow(byte[], int, int) - Method in interface org.apache.hadoop.hbase.RawCellBuilder
- setRowFilter(String) - Method in class org.apache.hadoop.hbase.wal.WALPrettyPrinter
-
sets the row key by which output will be filtered when not null, serves as a filter; only log entries from this row will be printed
- setRowFilter(Filter) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
-
Allows subclasses to set the
Filter
to be used. - setRowFilter(Filter) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
- setRowFilter(Filter) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
- setRowOffsetPerColumnFamily(int) - Method in class org.apache.hadoop.hbase.client.Get
-
Set offset for the row per Column Family.
- setRowOffsetPerColumnFamily(int) - Method in class org.apache.hadoop.hbase.client.ImmutableScan
- setRowOffsetPerColumnFamily(int) - Method in class org.apache.hadoop.hbase.client.Scan
-
Set offset for the row per Column Family.
- setRowPrefixFilter(byte[]) - Method in class org.apache.hadoop.hbase.client.Scan
-
Deprecated.since 2.5.0, will be removed in 4.0.0. The name of this method is considered to be confusing as it does not use a
Filter
but uses setting the startRow and stopRow instead. UseScan.setStartStopRowForPrefixScan(byte[])
instead. - setRowPrefixFilter(String) - Method in class org.apache.hadoop.hbase.wal.WALPrettyPrinter
-
sets the rowPrefix key prefix by which output will be filtered when not null, serves as a filter; only log entries with rows having this prefix will be printed
- setRpcServer(RpcServerInterface) - Method in class org.apache.hadoop.hbase.MockRegionServerServices
- setRpcTimeout(int) - Method in interface org.apache.hadoop.hbase.client.BufferedMutator
-
Deprecated.Since 3.0.0, will be removed in 4.0.0. Please set this through the
BufferedMutatorParams
. - setRpcTimeout(int) - Method in interface org.apache.hadoop.hbase.client.TableBuilder
-
Set timeout for each rpc request.
- setRpcTimeout(long, TimeUnit) - Method in interface org.apache.hadoop.hbase.client.AsyncAdminBuilder
-
Set timeout for each rpc request.
- setRpcTimeout(long, TimeUnit) - Method in interface org.apache.hadoop.hbase.client.AsyncBufferedMutatorBuilder
-
Set timeout for each rpc request when doing background flush.
- setRpcTimeout(long, TimeUnit) - Method in interface org.apache.hadoop.hbase.client.AsyncTableBuilder
-
Set timeout for each rpc request.
- setRSGroup(Set<TableName>, String) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Set the RegionServer group for tables
- setRSGroup(Set<TableName>, String) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Set the RegionServer group for tables
- setRSGroup(Set<TableName>, String) - Method in interface org.apache.hadoop.hbase.rsgroup.RSGroupInfoManager
-
Set group for tables.
- setRsRpcServices(RSRpcServices) - Method in class org.apache.hadoop.hbase.ipc.RpcServer
- setRsRpcServices(RSRpcServices) - Method in interface org.apache.hadoop.hbase.ipc.RpcServerInterface
- setRunning(boolean) - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSource.ReplicationLoadSourceBuilder
- setScan(Scan) - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord.OnlineLogRecordBuilder
- setScan(Scan) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
Sets the scan defining the actual details like columns etc.
- setScan(Scan) - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReader
-
Sets the scan defining the actual details like columns etc.
- setScan(Scan) - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReaderImpl
-
Sets the scan defining the actual details like columns etc.
- setScanMetricsEnabled(boolean) - Method in class org.apache.hadoop.hbase.client.ImmutableScan
- setScanMetricsEnabled(boolean) - Method in class org.apache.hadoop.hbase.client.Scan
-
Enable collection of
ScanMetrics
. - setScannerCaching(JobConf, int) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
-
Sets the number of rows to return and cache with each scanner iteration.
- setScannerCaching(Job, int) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Sets the number of rows to return and cache with each scanner iteration.
- setScans(List<Scan>) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableInputFormatBase
-
Allows subclasses to set the list of
Scan
objects. - setScanTimeout(long, TimeUnit) - Method in interface org.apache.hadoop.hbase.client.AsyncTableBuilder
-
As now we have heartbeat support for scan, ideally a scan will never timeout unless the RS is crash.
- setScope(int) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
- setSecond(int) - Method in class org.apache.hadoop.hbase.util.ObjectIntPair
- setSecond(B) - Method in class org.apache.hadoop.hbase.util.Triple
- setSecond(T2) - Method in class org.apache.hadoop.hbase.util.Pair
-
Replace the second element of the pair.
- setSecretManager(SecretManager<? extends TokenIdentifier>) - Method in class org.apache.hadoop.hbase.ipc.RpcServer
- setSecurityEnabled(boolean) - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
- setSequenceFilter(long) - Method in class org.apache.hadoop.hbase.wal.WALPrettyPrinter
-
sets the region by which output will be filtered when nonnegative, serves as a filter; only log entries with this sequence id will be printed
- setSequenceId(long) - Method in class org.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValue
- setSequenceId(long) - Method in class org.apache.hadoop.hbase.ByteBufferKeyValue
- setSequenceId(long) - Method in interface org.apache.hadoop.hbase.ExtendedCell
-
Sets with the given seqId.
- setSequenceId(long) - Method in interface org.apache.hadoop.hbase.ExtendedCellBuilder
-
Internal usage.
- setSequenceId(long) - Method in class org.apache.hadoop.hbase.ExtendedCellBuilderImpl
- setSequenceId(long) - Method in class org.apache.hadoop.hbase.IndividualBytesFieldCell
- setSequenceId(long) - Method in class org.apache.hadoop.hbase.KeyValue
- setSequenceId(long) - Method in class org.apache.hadoop.hbase.util.MapReduceExtendedCell
- setSequenceId(long) - Method in class org.apache.hadoop.hbase.wal.WALKeyImpl
- setSequenceId(Cell, long) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
Sets the given seqId to the cell.
- setSequenceID(long) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileReader
- setSerial(boolean) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeerConfigBuilder
-
Sets whether we should preserve order when replicating, i.e, serial replication.
- setServerClass(String) - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord.OnlineLogRecordBuilder
- setServerNames(List<ServerName>) - Method in class org.apache.hadoop.hbase.ClusterMetricsBuilder
- setServerOverloaded(boolean) - Method in exception org.apache.hadoop.hbase.HBaseServerException
-
Necessary for parsing RemoteException on client side
- setServerSideHConnectionRetriesConfig(Configuration, String, Logger) - Static method in class org.apache.hadoop.hbase.client.ConnectionUtils
-
Changes the configuration to set the number of retries needed when using Connection internally, e.g.
- setServiceStarted(boolean) - Method in class org.apache.hadoop.hbase.master.HMaster
-
Mainly used in procedure related tests, where we will restart ProcedureExecutor and AssignmentManager, but we do not want to restart master(to speed up the test), so we need to disable rpc for a while otherwise some critical rpc requests such as reportRegionStateTransition could fail and cause region server to abort.
- setSidelineBigOverlaps(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- setSidelineDir(String) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- setSignatureSecretFileKey(String) - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
- setSize(int) - Method in class org.apache.hadoop.hbase.replication.ReplicationEndpoint.ReplicateContext
- setSize(long) - Method in interface org.apache.hadoop.hbase.quotas.RegionSize
-
Updates the size of the Region.
- setSize(long) - Method in class org.apache.hadoop.hbase.quotas.RegionSizeImpl
- setSizeLimit(ScannerContext.LimitScope, long, long, long) - Method in class org.apache.hadoop.hbase.regionserver.ScannerContext.Builder
- setSizeOfLogQueue(int) - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSource.ReplicationLoadSourceBuilder
- setSkipChecks(boolean) - Method in class org.apache.hadoop.hbase.util.HbckRegionInfo
- setSkipWait(boolean) - Method in class org.apache.hadoop.hbase.util.compaction.MajorCompactor
- setSleepInterval(long) - Method in class org.apache.hadoop.hbase.util.RetryCounter.RetryConfig
- setSlowLogPayloads(List<TooSlowLog.SlowLogPayload>) - Method in class org.apache.hadoop.hbase.namequeues.response.NamedQueueGetResponse
- setSlowLogResponseRequest(AdminProtos.SlowLogResponseRequest) - Method in class org.apache.hadoop.hbase.namequeues.request.NamedQueueGetRequest
- setSnapshotDirs(Configuration, Map<String, Path>) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableSnapshotInputFormatImpl
- setSnapshotName(String) - Method in class org.apache.hadoop.hbase.backup.BackupTableInfo
- setSnapshotName(TableName, String) - Method in class org.apache.hadoop.hbase.backup.BackupInfo
- setSnapshotToScans(Configuration, Map<String, Collection<Scan>>) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableSnapshotInputFormatImpl
-
Push snapshotScans to conf (under the key
MultiTableSnapshotInputFormatImpl.SNAPSHOT_TO_SCANS_KEY
) - setSocketAddr(String, InetSocketAddress) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
- setSocketSendBufSize(int) - Method in class org.apache.hadoop.hbase.ipc.NettyRpcServer
- setSocketSendBufSize(int) - Method in interface org.apache.hadoop.hbase.ipc.RpcServerInterface
- setSocketSendBufSize(int) - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcServer
-
Deprecated.Sets the socket buffer size used for responding to RPCs.
- setSortField() - Method in class org.apache.hadoop.hbase.hbtop.screen.field.FieldScreenPresenter
- setSortFieldAndFields(Field, List<Field>) - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenModel
- setSource(MetricsThriftServerSource) - Method in class org.apache.hadoop.hbase.thrift.ThriftMetrics
- setSplit(boolean) - Method in class org.apache.hadoop.hbase.client.RegionInfoBuilder
- setSplitEnabled(boolean) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
- setSplitOrMergeEnabled(boolean, MasterSwitchType) - Method in class org.apache.hadoop.hbase.master.SplitOrMergeStateStore
- setSplitOrMergeEnabled(RpcController, MasterProtos.SetSplitOrMergeEnabledRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- setSplitRegions(int) - Method in class org.apache.hadoop.hbase.client.RegionStatesCount.RegionStatesCountBuilder
- setStartKey(byte[]) - Method in class org.apache.hadoop.hbase.client.RegionInfoBuilder
- setStartKey(Configuration, byte[]) - Static method in class org.apache.hadoop.hbase.mapreduce.SimpleTotalOrderPartitioner
- setStartLogErrorsCnt(int) - Method in interface org.apache.hadoop.hbase.client.AsyncAdminBuilder
-
Set the number of retries that are allowed before we start to log.
- setStartLogErrorsCnt(int) - Method in interface org.apache.hadoop.hbase.client.AsyncBufferedMutatorBuilder
-
Set the number of retries that are allowed before we start to log.
- setStartLogErrorsCnt(int) - Method in interface org.apache.hadoop.hbase.client.AsyncTableBuilder
-
Set the number of retries that are allowed before we start to log.
- setStartRow(byte[]) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
- setStartRow(byte[]) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
- setStartStopRowForPrefixScan(byte[]) - Method in class org.apache.hadoop.hbase.client.ImmutableScan
- setStartStopRowForPrefixScan(byte[]) - Method in class org.apache.hadoop.hbase.client.Scan
-
Set a filter (using stopRow and startRow) so the result set only contains rows where the rowKey starts with the specified prefix.
- setStartTime(long) - Method in class org.apache.hadoop.hbase.client.MetricsConnection.CallStats
- setStartTime(long) - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord.OnlineLogRecordBuilder
- setStartTime(long) - Method in interface org.apache.hadoop.hbase.ipc.RpcCall
-
Set the time when the call starts to be executed.
- setStartTime(long) - Method in class org.apache.hadoop.hbase.ipc.ServerCall
- setStartTime(long) - Method in class org.apache.hadoop.hbase.rest.RowSpec
- setStartTime(long) - Method in class org.apache.hadoop.hbase.ServerTaskBuilder
- setStartTs(long) - Method in class org.apache.hadoop.hbase.backup.BackupInfo
- setState(byte[]) - Method in class org.apache.hadoop.hbase.master.MasterStateStore
- setState(BackupInfo.BackupState) - Method in class org.apache.hadoop.hbase.backup.BackupInfo
- setState(ServerTask.State) - Method in class org.apache.hadoop.hbase.ServerTaskBuilder
- setStatistics(RegionLoadStats) - Method in class org.apache.hadoop.hbase.client.Result
-
Set load information about the region to the information about the result
- setStatus(String) - Method in class org.apache.hadoop.hbase.ServerTaskBuilder
- setStatus(MonitoredRPCHandler) - Method in class org.apache.hadoop.hbase.ipc.CallRunner
- setStatusOfTaskZNode(String, String) - Method in class org.apache.hadoop.hbase.chaos.ChaosAgent
-
sets given Status for Task Znode
- setSticky(boolean) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
The default behaviour is load balancing by sending each request to a random host.
- setStoragePolicy(String) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
- setStoragePolicy(String) - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
Set storage policy for a whole region.
- setStoragePolicy(String, String) - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
Set the directory of CF to the specified storage policy.
- setStoragePolicy(FileSystem, Path, String) - Static method in class org.apache.hadoop.hbase.util.CommonFSUtils
-
Sets storage policy for given path.
- setStoreCount(int) - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder
- setStoreFileCount(int) - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder
- setStoreFileIndexSize(Size) - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder
- setStoreFileRootLevelIndexSize(Size) - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder
- setStoreFileSize(Size) - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder
- setStoreFileUncompressedDataIndexSize(Size) - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder
- setStoreRefCount(int) - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder
- setStoreSequenceIds(Map<byte[], Long>) - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder
- setStrings(String, String...) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
- setSyncReplicationPeerInfoProvider(SyncReplicationPeerInfoProvider) - Method in class org.apache.hadoop.hbase.wal.AbstractWALProvider
- setSyncReplicationPeerInfoProvider(SyncReplicationPeerInfoProvider) - Method in interface org.apache.hadoop.hbase.wal.WALProvider
- setTable(Table) - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReader
- setTableCFsMap(Map<TableName, List<String>>) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeerConfigBuilder
-
Sets an explicit map of tables and column families in those tables that should be replicated to the given peer.
- setTableDescriptor(TableDescriptor) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
- setTableFilter(String) - Method in class org.apache.hadoop.hbase.quotas.QuotaFilter
-
Set the table filter regex
- setTableFilter(String) - Method in class org.apache.hadoop.hbase.wal.WALPrettyPrinter
-
Sets the tables filter.
- setTableInfo(HbckTableInfo) - Method in interface org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandler
-
Set the TableInfo used by all HRegionInfos fabricated by other callbacks
- setTableInfo(HbckTableInfo) - Method in class org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandlerImpl
-
Set the TableInfo used by all HRegionInfos fabricated by other callbacks
- setTableName(String) - Method in class org.apache.hadoop.hbase.client.LogQueryFilter
-
Deprecated.
- setTableName(TableName) - Method in class org.apache.hadoop.hbase.client.trace.TableOperationSpanBuilder
- setTableName(TableName) - Method in class org.apache.hadoop.hbase.client.trace.TableSpanBuilder
- setTableName(TableName) - Method in class org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
- setTableName(TableName) - Method in interface org.apache.hadoop.hbase.ipc.HBaseRpcController
-
Sets Region's table name.
- setTableName(TableName) - Method in class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
- setTableName(TableName) - Method in class org.apache.hadoop.hbase.quotas.policies.AbstractViolationPolicyEnforcement
- setTableQuota(TableName, MasterProtos.SetQuotaRequest) - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
- setTableRecordReader(TableRecordReader) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
-
Allows subclasses to set the
TableRecordReader
. - setTableRecordReader(TableRecordReader) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableInputFormatBase
-
Allows subclasses to set the
TableRecordReader
. - setTableRecordReader(TableRecordReader) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
Allows subclasses to set the
TableRecordReader
. - setTableRegionStatesCount(Map<TableName, RegionStatesCount>) - Method in class org.apache.hadoop.hbase.ClusterMetricsBuilder
- setTables(List<TableName>) - Method in class org.apache.hadoop.hbase.backup.BackupInfo
- setTableSetTimestampMap(Map<TableName, Map<String, Long>>) - Method in class org.apache.hadoop.hbase.backup.BackupInfo
- setTableState(TableName, TableState.State) - Method in class org.apache.hadoop.hbase.master.TableStateManager
-
Set table state to provided.
- setTableStateInMeta(TableState) - Method in class org.apache.hadoop.hbase.client.HBaseHbck
- setTableStateInMeta(TableState) - Method in interface org.apache.hadoop.hbase.client.Hbck
-
Update table state in Meta only.
- setTableStateInMeta(RpcController, MasterProtos.SetTableStateInMetaRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
Update state of the table in meta only.
- setTagCompressionContext(TagCompressionContext) - Method in class org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultDecodingContext
- setTagCompressionContext(TagCompressionContext) - Method in class org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultEncodingContext
- setTags(byte[]) - Method in interface org.apache.hadoop.hbase.ExtendedCellBuilder
- setTags(byte[]) - Method in class org.apache.hadoop.hbase.ExtendedCellBuilderImpl
- setTags(byte[], int, int) - Method in interface org.apache.hadoop.hbase.ExtendedCellBuilder
- setTags(byte[], int, int) - Method in class org.apache.hadoop.hbase.ExtendedCellBuilderImpl
- setTags(List<Tag>) - Method in interface org.apache.hadoop.hbase.ExtendedCellBuilder
- setTags(List<Tag>) - Method in class org.apache.hadoop.hbase.ExtendedCellBuilderImpl
- setTags(List<Tag>) - Method in interface org.apache.hadoop.hbase.RawCellBuilder
- setTagType(byte) - Method in interface org.apache.hadoop.hbase.TagBuilder
-
Set type of the tag.
- setTagValue(byte[]) - Method in interface org.apache.hadoop.hbase.TagBuilder
-
Set the value of the tag.
- setTargetTableName(String[]) - Method in class org.apache.hadoop.hbase.master.RegionPlacementMaintainer
- setTaskNode(String) - Method in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination.ZkSplitTaskDetails
- setTasks(List<ServerTask>) - Method in class org.apache.hadoop.hbase.ServerMetricsBuilder
- setThird(C) - Method in class org.apache.hadoop.hbase.util.Triple
- setThreads(int, int) - Method in class org.apache.hadoop.hbase.http.HttpServer
-
Set the min, max number of worker threads (simultaneous connections).
- setTickTime(int) - Method in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
- setTimeDuration(String, long, TimeUnit) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
- setTimeLag(long) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.We are interested in only those tables that have not changed their state in hbase:meta during the last few seconds specified by hbase.admin.fsck.timelag
- setTimeLimit(ScannerContext.LimitScope, long) - Method in class org.apache.hadoop.hbase.regionserver.ScannerContext.Builder
- setTimeout(int) - Method in class org.apache.hadoop.hbase.replication.ReplicationEndpoint.ReplicateContext
- setTimeoutForWriteLock(long) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
The
HRegion.doClose(boolean, org.apache.hadoop.hbase.monitoring.MonitoredTask)
will block forever if someone tries proving the dead lock via the unit test. - setTimer(long) - Method in class org.apache.hadoop.hbase.hbtop.screen.AbstractScreenView
- setTimer(long) - Method in class org.apache.hadoop.hbase.hbtop.screen.Screen
- setTimeRange(long, long) - Method in class org.apache.hadoop.hbase.client.Append
-
Sets the TimeRange to be used on the Get for this append.
- setTimeRange(long, long) - Method in class org.apache.hadoop.hbase.client.Get
-
Get versions of columns only within the specified timestamp range, [minStamp, maxStamp).
- setTimeRange(long, long) - Method in class org.apache.hadoop.hbase.client.ImmutableScan
- setTimeRange(long, long) - Method in class org.apache.hadoop.hbase.client.Increment
-
Sets the TimeRange to be used on the Get for this increment.
- setTimeRange(long, long) - Method in class org.apache.hadoop.hbase.client.Scan
-
Get versions of columns only within the specified timestamp range, [minStamp, maxStamp).
- setTimestamp(byte[]) - Method in class org.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValue
- setTimestamp(byte[]) - Method in class org.apache.hadoop.hbase.ByteBufferKeyValue
- setTimestamp(byte[]) - Method in interface org.apache.hadoop.hbase.ExtendedCell
-
Sets with the given timestamp.
- setTimestamp(byte[]) - Method in class org.apache.hadoop.hbase.IndividualBytesFieldCell
- setTimestamp(byte[]) - Method in class org.apache.hadoop.hbase.KeyValue
- setTimestamp(byte[]) - Method in class org.apache.hadoop.hbase.util.MapReduceExtendedCell
- setTimestamp(long) - Method in class org.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValue
- setTimestamp(long) - Method in class org.apache.hadoop.hbase.ByteBufferKeyValue
- setTimestamp(long) - Method in interface org.apache.hadoop.hbase.CellBuilder
- setTimestamp(long) - Method in class org.apache.hadoop.hbase.client.Append
- setTimestamp(long) - Method in class org.apache.hadoop.hbase.client.Delete
- setTimestamp(long) - Method in class org.apache.hadoop.hbase.client.Get
-
Get versions of columns with the specified timestamp.
- setTimestamp(long) - Method in class org.apache.hadoop.hbase.client.ImmutableScan
- setTimestamp(long) - Method in class org.apache.hadoop.hbase.client.Increment
- setTimestamp(long) - Method in class org.apache.hadoop.hbase.client.Mutation
-
Set the timestamp of the delete.
- setTimestamp(long) - Method in class org.apache.hadoop.hbase.client.Put
- setTimestamp(long) - Method in class org.apache.hadoop.hbase.client.Scan
-
Get versions of columns with the specified timestamp.
- setTimestamp(long) - Method in interface org.apache.hadoop.hbase.ExtendedCell
-
Sets with the given timestamp.
- setTimestamp(long) - Method in interface org.apache.hadoop.hbase.ExtendedCellBuilder
- setTimestamp(long) - Method in class org.apache.hadoop.hbase.ExtendedCellBuilderImpl
- setTimestamp(long) - Method in class org.apache.hadoop.hbase.IndividualBytesFieldCell
- setTimestamp(long) - Method in class org.apache.hadoop.hbase.KeyValue
- setTimestamp(long) - Method in interface org.apache.hadoop.hbase.RawCellBuilder
- setTimestamp(long) - Method in class org.apache.hadoop.hbase.util.MapReduceExtendedCell
- setTimestamp(Cell, byte[]) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
Sets the given timestamp to the cell.
- setTimestamp(Cell, byte[], int) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Sets the given timestamp to the cell.
- setTimestamp(Cell, long) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Sets the given timestamp to the cell.
- setTimestamp(Cell, long) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
Sets the given timestamp to the cell.
- setTimestampOfLastShippedOp(long) - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSource.ReplicationLoadSourceBuilder
- setTimeStampOfNextToReplicate(long) - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSource.ReplicationLoadSourceBuilder
- setTimestampsOfLastAppliedOp(long) - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSink.ReplicationLoadSinkBuilder
- setTimestampStarted(long) - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSink.ReplicationLoadSinkBuilder
- setTimeToLive(int) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
- setTimeToLive(String) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
- setTimeToPurgeDeletes(long) - Method in class org.apache.hadoop.hbase.regionserver.CustomizedScanInfoBuilder
- setTimeToPurgeDeletes(long) - Method in interface org.apache.hadoop.hbase.regionserver.ScanOptions
- setTimeUnit(TimeUnit) - Method in class org.apache.hadoop.hbase.util.RetryCounter.RetryConfig
- setTitle(String) - Static method in class org.apache.hadoop.hbase.hbtop.terminal.impl.EscapeSequences
- setToNewRow(ExtendedCell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher
-
Set the row when there is change in row
- setTotalBytesCopied(long) - Method in class org.apache.hadoop.hbase.backup.BackupInfo
- setTotalOpsProcessed(long) - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSink.ReplicationLoadSinkBuilder
- setTotalRegions(int) - Method in class org.apache.hadoop.hbase.client.RegionStatesCount.RegionStatesCountBuilder
- setTotalUncompressedBytes(long) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
- setTrackMetrics(boolean) - Method in class org.apache.hadoop.hbase.regionserver.ScannerContext.Builder
- setTrackWroteKeys(boolean) - Method in class org.apache.hadoop.hbase.util.MultiThreadedWriterBase
-
Used for a joint write/read workload.
- setTrailer(FixedFileTrailer) - Method in class org.apache.hadoop.hbase.io.hfile.HFileInfo
- setTTL(long) - Method in class org.apache.hadoop.hbase.client.Append
- setTTL(long) - Method in class org.apache.hadoop.hbase.client.Delete
- setTTL(long) - Method in class org.apache.hadoop.hbase.client.Increment
- setTTL(long) - Method in class org.apache.hadoop.hbase.client.Mutation
-
Set the TTL desired for the result of the mutation, in milliseconds.
- setTTL(long) - Method in class org.apache.hadoop.hbase.client.Put
- setTTL(long) - Method in class org.apache.hadoop.hbase.regionserver.CustomizedScanInfoBuilder
- setTTL(long) - Method in interface org.apache.hadoop.hbase.regionserver.ScanOptions
- setType(byte) - Method in interface org.apache.hadoop.hbase.ExtendedCellBuilder
- setType(byte) - Method in class org.apache.hadoop.hbase.ExtendedCellBuilderImpl
- setType(BackupType) - Method in class org.apache.hadoop.hbase.backup.BackupInfo
- setType(Cell.Type) - Method in interface org.apache.hadoop.hbase.CellBuilder
- setType(Cell.Type) - Method in interface org.apache.hadoop.hbase.ExtendedCellBuilder
- setType(Cell.Type) - Method in class org.apache.hadoop.hbase.ExtendedCellBuilderImpl
- setType(Cell.Type) - Method in interface org.apache.hadoop.hbase.RawCellBuilder
- setType(LogQueryFilter.Type) - Method in class org.apache.hadoop.hbase.client.LogQueryFilter
-
Deprecated.
- setUnassigned() - Method in class org.apache.hadoop.hbase.master.SplitLogManager.Task
-
Deprecated.
- setUnblockedFlushCount(long) - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerContext
- setUncompressedDataIndexSize(long) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
- setUncompressedStoreFileSize(Size) - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder
- setUnderline(boolean) - Method in class org.apache.hadoop.hbase.hbtop.terminal.Attributes
- setUnknownServerNames(List<ServerName>) - Method in class org.apache.hadoop.hbase.ClusterMetricsBuilder
- setUnknownServerRegions(int) - Method in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
-
Set the number of unknown server regions.
- setUnknownServerRegions(int) - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManagerSourceImpl
- setup(Configuration, String) - Static method in class org.apache.hadoop.hbase.util.NettyEventLoopGroupConfig
- setup(RegionServerServices) - Method in class org.apache.hadoop.hbase.regionserver.throttle.NoLimitThroughputController
- setup(RegionServerServices) - Method in class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareCompactionThroughputController
- setup(RegionServerServices) - Method in class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareFlushThroughputController
- setup(RegionServerServices) - Method in class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareThroughputController
- setup(RegionServerServices) - Method in interface org.apache.hadoop.hbase.regionserver.throttle.ThroughputController
-
Setup controller for the given region server.
- setup(Mapper.Context) - Method in class org.apache.hadoop.hbase.mapreduce.Import.CellImporter
- setup(Mapper.Context) - Method in class org.apache.hadoop.hbase.mapreduce.Import.Importer
- setup(Mapper.Context) - Method in class org.apache.hadoop.hbase.mapreduce.SyncTable.SyncMapper
- setup(Mapper.Context) - Method in class org.apache.hadoop.hbase.mapreduce.IndexBuilder.Map
- setup(Mapper.Context) - Method in class org.apache.hadoop.hbase.mapreduce.HashTable.HashMapper
- setup(Mapper.Context) - Method in class org.apache.hadoop.hbase.mapreduce.Import.CellSortImporter
- setup(Mapper.Context) - Method in class org.apache.hadoop.hbase.mapreduce.WALPlayer.WALMapper
- setup(Mapper.Context) - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
-
Handles initializing this class with objects specific to it (i.e., the parser).
- setup(Mapper.Context) - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterTextMapper
-
Handles initializing this class with objects specific to it (i.e., the parser).
- setup(Mapper.Context) - Method in class org.apache.hadoop.hbase.PerformanceEvaluation.EvaluationMapTask
- setup(Reducer.Context) - Method in class org.apache.hadoop.hbase.mapreduce.PutSortReducer
- setup(Reducer.Context) - Method in class org.apache.hadoop.hbase.mapreduce.TextSortReducer
-
Handles initializing this class with objects specific to it (i.e., the parser).
- setup(Reducer.Context) - Method in class org.apache.hadoop.hbase.mob.mapreduce.MobRefReporter.MobRefReducer
- setupClusterConnection() - Method in class org.apache.hadoop.hbase.HBaseServerBase
-
Setup our cluster connection if not already initialized.
- setupClusterTestDir() - Method in class org.apache.hadoop.hbase.HBaseZKTestingUtility
-
Deprecated.Creates a directory for the cluster, under the test data
- setupDataTestDir() - Method in class org.apache.hadoop.hbase.HBaseCommonTestingUtility
-
Deprecated.Sets up a directory for a test to use.
- setupDataTestDir() - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Home our data in a dir under
HBaseCommonTestingUtility.DEFAULT_BASE_TEST_DIRECTORY
. - setupDataTestDir() - Method in class org.apache.hadoop.hbase.util.WALPerformanceEvaluationUtil
-
Home our data in a dir under
WALPerformanceEvaluationUtil.DEFAULT_BASE_TEST_DIRECTORY
. - setupHTTPServer() - Method in class org.apache.hadoop.hbase.thrift.ThriftServer
-
Setup an HTTP Server using Jetty to serve calls from THttpClient
- setupJob(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputCommitter
- setupMiniKdc(File) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Sets up
MiniKdc
for testing security. - setupParamters() - Method in class org.apache.hadoop.hbase.thrift.ThriftServer
- setupSaslHandler(ChannelPipeline, String) - Method in class org.apache.hadoop.hbase.security.NettyHBaseSaslRpcClient
- setupServer() - Method in class org.apache.hadoop.hbase.thrift.ThriftServer
-
Setting up the thrift TServer
- setupSetQuotaRequest(MasterProtos.SetQuotaRequest.Builder) - Method in class org.apache.hadoop.hbase.quotas.GlobalQuotaSettings
- setupSetQuotaRequest(MasterProtos.SetQuotaRequest.Builder) - Method in class org.apache.hadoop.hbase.quotas.QuotaSettings
-
Called by toSetQuotaRequestProto() the subclass should implement this method to set the specific SetQuotaRequest properties.
- setupSetQuotaRequest(MasterProtos.SetQuotaRequest.Builder) - Method in class org.apache.hadoop.hbase.quotas.ThrottleSettings
- setupShortCircuitRead(Configuration) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Do our short circuit read setup.
- setupTask(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputCommitter
- setUsedHeapSize(Size) - Method in class org.apache.hadoop.hbase.ServerMetricsBuilder
- setUseExecutor(boolean) - Method in class org.apache.hadoop.hbase.regionserver.CompactedHFilesDischarger
-
CompactedHFilesDischarger runs asynchronously by default using the hosting RegionServer's Executor.
- setUserFilter(String) - Method in class org.apache.hadoop.hbase.quotas.QuotaFilter
-
Set the user filter regex
- setUserMetrics(List<UserMetrics>) - Method in class org.apache.hadoop.hbase.ServerMetricsBuilder
- setUserName(String) - Method in class org.apache.hadoop.hbase.client.LogQueryFilter
-
Deprecated.
- setUserName(String) - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord.OnlineLogRecordBuilder
- setUsernameConfKey(String) - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
- setUserProviderForTesting(Configuration, Class<? extends UserProvider>) - Static method in class org.apache.hadoop.hbase.security.UserProvider
-
Set the
UserProvider
in the given configuration that should be instantiated - setUserQuota(String, String, MasterProtos.SetQuotaRequest) - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
- setUserQuota(String, MasterProtos.SetQuotaRequest) - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
- setUserQuota(String, TableName, MasterProtos.SetQuotaRequest) - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
- setValue(byte[]) - Method in interface org.apache.hadoop.hbase.CellBuilder
- setValue(byte[]) - Method in interface org.apache.hadoop.hbase.ExtendedCellBuilder
- setValue(byte[]) - Method in class org.apache.hadoop.hbase.ExtendedCellBuilderImpl
- setValue(byte[]) - Method in interface org.apache.hadoop.hbase.RawCellBuilder
- setValue(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
- setValue(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
- setValue(byte[], int, int) - Method in interface org.apache.hadoop.hbase.CellBuilder
- setValue(byte[], int, int) - Method in interface org.apache.hadoop.hbase.ExtendedCellBuilder
- setValue(byte[], int, int) - Method in class org.apache.hadoop.hbase.ExtendedCellBuilderImpl
- setValue(byte[], int, int) - Method in interface org.apache.hadoop.hbase.RawCellBuilder
- setValue(long) - Method in class org.apache.hadoop.hbase.util.ManualEnvironmentEdge
- setValue(String, String) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
- setValue(String, String) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
- setValue(Bytes, Bytes) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
- setValue(Bytes, Bytes) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
- setVersion(String) - Method in class org.apache.hadoop.hbase.ServerMetricsBuilder
- setVersion(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Sets version of file system
- setVersion(FileSystem, Path, int, int) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Sets version of file system
- setVersion(FileSystem, Path, String, int, int) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Sets version of file system
- setVersionNumber(int) - Method in class org.apache.hadoop.hbase.ServerMetricsBuilder
- setVersionsWithTimeToLive(int, int) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
- setVictimCache(BlockCache) - Method in interface org.apache.hadoop.hbase.io.hfile.FirstLevelBlockCache
-
Specifies the secondary cache.
- setVictimCache(BlockCache) - Method in class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache
- setVictimCache(BlockCache) - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
- setVictimCache(BlockCache) - Method in class org.apache.hadoop.hbase.io.hfile.TinyLfuBlockCache
- setWaitOnShutdownInSeconds(int, String) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
- setWalEdit(int, WALEdit) - Method in class org.apache.hadoop.hbase.regionserver.MiniBatchOperationInProgress
-
Sets the walEdit for the operation(Mutation) at the specified position.
- setWalEditForReplicateIfExistsSkipWAL(WALEdit) - Method in class org.apache.hadoop.hbase.regionserver.MiniBatchOperationInProgress
- setWalGroupId(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationEndpoint.ReplicateContext
- setWALRootDir(Configuration, Path) - Static method in class org.apache.hadoop.hbase.util.CommonFSUtils
- setWatchIfNodeExists(ZKWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Watch the specified znode, but only if exists.
- setWithPrefix(Configuration, String, Iterable<Map.Entry<String, String>>) - Static method in class org.apache.hadoop.hbase.HBaseConfiguration
-
Sets all the entries in the provided
Map<String, String>
as properties in the givenConfiguration
. - setWorkers(int) - Method in class org.apache.hadoop.hbase.backup.BackupInfo
- setWriteBufferPeriodicFlush(long) - Method in interface org.apache.hadoop.hbase.client.BufferedMutator
-
Sets the maximum time before the buffer is automatically flushed checking once per second.
- setWriteBufferPeriodicFlush(long, long) - Method in interface org.apache.hadoop.hbase.client.BufferedMutator
-
Sets the maximum time before the buffer is automatically flushed.
- setWriteBufferPeriodicFlush(long, TimeUnit) - Method in interface org.apache.hadoop.hbase.client.AsyncBufferedMutatorBuilder
-
Set the periodical flush interval.
- setWriteBufferPeriodicFlushTimeoutMs(long) - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
-
Set the max timeout before the buffer is automatically flushed.
- setWriteBufferPeriodicFlushTimerTickMs(long) - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
-
Deprecated.Since 3.0.0, will be removed in 4.0.0. We use a common timer in the whole client implementation so you can not set it any more.
- setWriteBufferSize(long) - Method in interface org.apache.hadoop.hbase.client.AsyncBufferedMutatorBuilder
-
Override the write buffer size specified by the provided
AsyncConnection
'sConfiguration
instance, via the configuration keyhbase.client.write.buffer
. - setWriteEntry(MultiVersionConcurrencyControl.WriteEntry) - Method in class org.apache.hadoop.hbase.wal.WALKeyImpl
- setWriteRequestCount(long) - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder
- setWriteRequestCount(long) - Method in class org.apache.hadoop.hbase.ServerMetricsBuilder
- setWriteRpcTimeout(int) - Method in interface org.apache.hadoop.hbase.client.TableBuilder
-
Set timeout for each write(put, delete) rpc request.
- setWriteRpcTimeout(long, TimeUnit) - Method in interface org.apache.hadoop.hbase.client.AsyncTableBuilder
-
Set timeout for each write(put, delete) rpc request.
- setYarnPoolName(String) - Method in class org.apache.hadoop.hbase.backup.BackupRequest
- setZkCluster(MiniZooKeeperCluster) - Method in class org.apache.hadoop.hbase.HBaseZKTestingUtility
-
Deprecated.
- SEVENTY_FIFTH_PERCENTILE_METRIC_NAME - Static variable in interface org.apache.hadoop.metrics2.MetricHistogram
- SHALLOW_COPY - Enum constant in enum class org.apache.hadoop.hbase.CellBuilderType
-
DON'T modify the byte array passed to cell builder because all fields in new cell are reference to input arguments
- shallowCopy() - Method in class org.apache.hadoop.hbase.KeyValue
-
Creates a shallow copy of this KeyValue, reusing the data byte buffer.
- shallowCopy() - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Create a new
ByteRange
that points at this range's byte[]. - shallowCopy() - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
- shallowCopy() - Method in class org.apache.hadoop.hbase.util.SimpleByteRange
- shallowCopy() - Method in class org.apache.hadoop.hbase.util.SimpleMutableByteRange
- shallowCopy() - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
- shallowCopy() - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
- shallowCopySubRange(int, int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Create a new
ByteRange
that points at this range's byte[]. - shallowCopySubRange(int, int) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
- shallowCopySubRange(int, int) - Method in class org.apache.hadoop.hbase.util.SimpleByteRange
- shallowCopySubRange(int, int) - Method in class org.apache.hadoop.hbase.util.SimpleMutableByteRange
- shallowCopySubRange(int, int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
- shallowCopySubRange(int, int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
- org.apache.hadoop.hbase.client.SharedAsyncConnection - Class in org.apache.hadoop.hbase.client
-
Wraps a
AsyncConnection
to make it can't be closed. - SharedAsyncConnection(AsyncConnection) - Constructor for class org.apache.hadoop.hbase.client.SharedAsyncConnection
- org.apache.hadoop.hbase.client.SharedConnection - Class in org.apache.hadoop.hbase.client
-
Wraps a
Connection
to make it can't be closed or aborted. - SharedConnection(Connection) - Constructor for class org.apache.hadoop.hbase.client.SharedConnection
- sharedLock() - Method in class org.apache.hadoop.hbase.regionserver.Segment
- org.apache.hadoop.hbase.io.hfile.SharedMemHFileBlock - Class in org.apache.hadoop.hbase.io.hfile
-
The
ByteBuffAllocator
won't allocate pooled heapByteBuff
now; at the same time, if allocate an off-heapByteBuff
from allocator, then it must be a pooled one. - sharedUnlock() - Method in class org.apache.hadoop.hbase.regionserver.Segment
- SHELL_TIMESTAMP_FORMAT_EPOCH_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
- shipped() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
- shipped() - Method in class org.apache.hadoop.hbase.regionserver.KeyValueHeap
- shipped() - Method in class org.apache.hadoop.hbase.regionserver.MobStoreScanner
- shipped() - Method in class org.apache.hadoop.hbase.regionserver.NonLazyKeyValueScanner
- shipped() - Method in class org.apache.hadoop.hbase.regionserver.ReversedMobStoreScanner
- shipped() - Method in class org.apache.hadoop.hbase.regionserver.SegmentScanner
-
Called after a batch of rows scanned (RPC) and set to be returned to client.
- shipped() - Method in interface org.apache.hadoop.hbase.regionserver.Shipper
-
Called after a batch of rows scanned and set to be returned to client.
- shipped() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
- shipped() - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
- org.apache.hadoop.hbase.regionserver.Shipper - Interface in org.apache.hadoop.hbase.regionserver
-
This interface denotes a scanner as one which can ship cells.
- org.apache.hadoop.hbase.regionserver.ShipperListener - Interface in org.apache.hadoop.hbase.regionserver
-
Implementors of this interface are the ones who needs to do some action when the
Shipper.shipped()
is called - SHORT_HELP_OPTION - Static variable in class org.apache.hadoop.hbase.util.AbstractHBaseTool
- SHORTCIRCUIT_BYTES_READ - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- SHORTCIRCUIT_BYTES_READ_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- SHOULD_NOT_BE_DEPLOYED - Enum constant in enum class org.apache.hadoop.hbase.util.HbckErrorReporter.ERROR_CODE
-
Deprecated.
- shouldBypass() - Method in class org.apache.hadoop.hbase.coprocessor.ObserverContextImpl
- shouldCacheBlockOnRead(BlockType.BlockCategory) - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
Should we cache a block of a particular category? We always cache important blocks such as index blocks, as long as the block cache is available.
- shouldCacheBloomsOnWrite() - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
- shouldCacheCompactedBlocksOnWrite() - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
Returns true if blocks should be cached while writing during compaction, false if not
- shouldCacheCompressed(BlockType.BlockCategory) - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
Returns true if this
BlockType.BlockCategory
should be compressed in blockcache, false otherwise - shouldCacheDataCompressed() - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
Returns true if data blocks should be compressed in the cache, false if not
- shouldCacheDataOnRead() - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
Returns whether the DATA blocks of this HFile should be cached on read or not (we always cache the meta blocks, the INDEX and BLOOM blocks).
- shouldCacheDataOnWrite() - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
- shouldCacheFile(String) - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCache
-
Checks whether blocks for the passed file should be cached or not.
- shouldCacheFile(String) - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
- shouldCacheIndexesOnWrite() - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
- shouldCheckBulkLoads() - Method in class org.apache.hadoop.hbase.quotas.policies.DefaultViolationPolicyEnforcement
- shouldCheckBulkLoads() - Method in class org.apache.hadoop.hbase.quotas.policies.MissingSnapshotViolationPolicyEnforcement
- shouldCheckBulkLoads() - Method in interface org.apache.hadoop.hbase.quotas.SpaceViolationPolicyEnforcement
-
Returns whether thet caller should verify any bulk loads against
this
. - shouldDispatchToScanQueue(CallRunner) - Method in class org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
- shouldDisplayFullReport() - Static method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- shouldDropBehind - Variable in class org.apache.hadoop.hbase.io.hfile.HFile.WriterFactory
- shouldDropBehind() - Method in class org.apache.hadoop.hbase.regionserver.CreateStoreFileWriterParams
- shouldDropBehind(boolean) - Method in class org.apache.hadoop.hbase.regionserver.CreateStoreFileWriterParams
- shouldDropBehindCompaction() - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
- shouldEnableHistoricalCompactionFiles(Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFileWriter
- shouldEvictOnClose() - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
- shouldFinishBlock(int) - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCompressedSizePredicator
-
Decides if the block should be finished based on the comparison of its uncompressed size against an adjusted size based on a predicated compression factor.
- shouldFinishBlock(int) - Method in class org.apache.hadoop.hbase.io.hfile.PreviousBlockCompressionRatePredicator
-
Returns true if the passed uncompressed size is larger than the limit calculated by
updateLatestBlockSizes
. - shouldFinishBlock(int) - Method in class org.apache.hadoop.hbase.io.hfile.UncompressedBlockSizePredicator
-
Dummy implementation that always returns true.
- shouldFixVersionFile() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- shouldFlush(HStore) - Method in class org.apache.hadoop.hbase.regionserver.FlushAllLargeStoresPolicy
- shouldFlush(HStore) - Method in class org.apache.hadoop.hbase.regionserver.FlushLargeStoresPolicy
- shouldIgnorePreCheckPermission() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- shouldIncludeMemStoreTS() - Method in class org.apache.hadoop.hbase.io.hfile.HFileInfo
- shouldIncludeStore(HRegionFileSystem, String, Collection<StoreFileInfo>, long) - Method in class org.apache.hadoop.hbase.util.compaction.MajorCompactionTTLRequest
- shouldLockOnCacheMiss(BlockType) - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
If we make sure the block could not be cached, we will not acquire the lock otherwise we will acquire lock
- shouldLoginFromKeytab() - Method in class org.apache.hadoop.hbase.security.UserProvider
-
In secure environment, if a user specified his keytab and principal, a hbase client will try to login with them.
- shouldLoginFromKeytab(Configuration) - Static method in class org.apache.hadoop.hbase.security.User
-
In secure environment, if a user specified his keytab and principal, a hbase client will try to login with them.
- shouldPerformMajorCompaction() - Method in class org.apache.hadoop.hbase.regionserver.HStore
- shouldPerformMajorCompaction() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Tests whether we should run a major compaction.
- shouldPrefetchOnOpen() - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
Returns true if blocks should be prefetched into the cache on open, false if not
- shouldReadBlockFromCache(BlockType) - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
Return true if we may find this type of block in block cache.
- shouldReplaceExistingCacheBlock(BlockCache, BlockCacheKey, Cacheable) - Static method in class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil
-
Because of the region splitting, it's possible that the split key locate in the middle of a block.
- shouldReplayRecoveredEdits(HRegion) - Static method in class org.apache.hadoop.hbase.util.ServerRegionReplicaUtil
-
Returns whether to replay the recovered edits to flush the results.
- shouldReplicate(ReplicationGroupOffset, String) - Static method in class org.apache.hadoop.hbase.replication.ReplicationOffsetUtil
- shouldRerun() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- shouldRetry() - Method in class org.apache.hadoop.hbase.util.RetryCounter
- shouldRetryCreate(RemoteException) - Static method in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputHelper
- shouldSeek(TimeRange, long) - Method in class org.apache.hadoop.hbase.regionserver.CompositeImmutableSegment
- shouldSeek(TimeRange, long) - Method in class org.apache.hadoop.hbase.regionserver.Segment
- shouldShutDownConsumeExecutorWhenClose - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
- shouldSidelineBigOverlaps() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- shouldSplit() - Method in class org.apache.hadoop.hbase.regionserver.BusyRegionSplitPolicy
- shouldSplit() - Method in class org.apache.hadoop.hbase.regionserver.ConstantSizeRegionSplitPolicy
- shouldSplit() - Method in class org.apache.hadoop.hbase.regionserver.DisabledRegionSplitPolicy
- shouldSplit() - Method in class org.apache.hadoop.hbase.regionserver.IncreasingToUpperBoundRegionSplitPolicy
- shouldSplit() - Method in class org.apache.hadoop.hbase.regionserver.RegionSplitPolicy
-
Returns true if the specified region should be split.
- shouldUseHBaseChecksum() - Method in class org.apache.hadoop.hbase.io.FSDataInputStreamWrapper
-
Returns Whether we are presently using HBase checksum.
- shouldUseScanner(Scan, HStore, long) - Method in interface org.apache.hadoop.hbase.regionserver.KeyValueScanner
-
Allows to filter out scanners (both StoreFile and memstore) that we don't want to use based on criteria such as Bloom filters and timestamp ranges.
- shouldUseScanner(Scan, HStore, long) - Method in class org.apache.hadoop.hbase.regionserver.NonLazyKeyValueScanner
- shouldUseScanner(Scan, HStore, long) - Method in class org.apache.hadoop.hbase.regionserver.SegmentScanner
-
This functionality should be resolved in the higher level which is MemStoreScanner, currently returns true as default.
- shouldUseScanner(Scan, HStore, long) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
- shouldWriteBlock(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.CompoundBloomFilterWriter
- shouldWriteBlock(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexWriter
-
Whether there is an inline block ready to be written.
- shouldWriteBlock(boolean) - Method in interface org.apache.hadoop.hbase.io.hfile.InlineBlockWriter
-
Determines whether there is a new block to be written out.
- SHOW - Enum constant in enum class org.apache.hadoop.hbase.backup.BackupRestoreConstants.BackupCommand
- showField(int, Field, boolean, boolean, int, int, boolean) - Method in class org.apache.hadoop.hbase.hbtop.screen.field.FieldScreenView
- showFieldScreen(String, List<Field>, EnumMap<Field, Boolean>, int, int, int, boolean) - Method in class org.apache.hadoop.hbase.hbtop.screen.field.FieldScreenView
- showFilters(List<RecordFilter>) - Method in class org.apache.hadoop.hbase.hbtop.screen.top.FilterDisplayModeScreenView
- showHelpScreen(long, CommandDescription[]) - Method in class org.apache.hadoop.hbase.hbtop.screen.help.HelpScreenView
- showInput(String, String, int) - Method in class org.apache.hadoop.hbase.hbtop.screen.top.InputModeScreenView
- showMessage(String) - Method in class org.apache.hadoop.hbase.hbtop.screen.top.MessageModeScreenView
- showMode(int, Mode, boolean, int, int) - Method in class org.apache.hadoop.hbase.hbtop.screen.mode.ModeScreenView
- showModeScreen(Mode, List<Mode>, int, int, int) - Method in class org.apache.hadoop.hbase.hbtop.screen.mode.ModeScreenView
- showScreenDescription(String) - Method in class org.apache.hadoop.hbase.hbtop.screen.field.FieldScreenView
- showTopScreen(Summary, List<Header>, List<Record>, Record) - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenView
- SHUFFLE_MAPS - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
Specify if we have to shuffle the map tasks.
- shutdown - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
- shutdown() - Method in class org.apache.hadoop.hbase.ChoreService
-
Shut down the service.
- shutdown() - Method in interface org.apache.hadoop.hbase.client.Admin
-
Shuts down the HBase cluster.
- shutdown() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Shuts down the HBase cluster.
- shutdown() - Method in class org.apache.hadoop.hbase.coprocessor.BaseEnvironment
-
Clean up the environment
- shutdown() - Method in class org.apache.hadoop.hbase.HBaseCluster
-
Deprecated.Shut down the HBase cluster
- shutdown() - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCache
-
Shutdown the cache.
- shutdown() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
- shutdown() - Method in class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache
- shutdown() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
- shutdown() - Method in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
- shutdown() - Method in class org.apache.hadoop.hbase.io.hfile.TinyLfuBlockCache
- shutdown() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
Shut down the mini HBase cluster
- shutdown() - Method in class org.apache.hadoop.hbase.master.HMaster
-
Shutdown the cluster.
- shutdown() - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.Shut down the mini HBase cluster
- shutdown() - Method in class org.apache.hadoop.hbase.mob.MobFileCache
- shutdown() - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
- shutdown() - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Shut down the client.
- shutdown() - Method in class org.apache.hadoop.hbase.ScheduledChore
-
Call
ScheduledChore.shutdown(boolean)
withtrue
. - shutdown() - Method in class org.apache.hadoop.hbase.util.compaction.MajorCompactor
- shutdown() - Method in class org.apache.hadoop.hbase.util.ConnectionCache
-
Called when cache is no longer needed so that it can perform cleanup operations
- shutdown() - Method in class org.apache.hadoop.hbase.wal.AbstractWALProvider
- shutdown() - Method in interface org.apache.hadoop.hbase.wal.WAL
-
Stop accepting new writes.
- shutdown() - Method in class org.apache.hadoop.hbase.wal.WALFactory
-
Tell the underlying WAL providers to shut down, but do not clean up underlying storage.
- shutdown() - Method in interface org.apache.hadoop.hbase.wal.WALProvider
-
persist outstanding WALs to storage and stop accepting new appends.
- shutdown() - Method in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
- shutdown(boolean) - Method in class org.apache.hadoop.hbase.ScheduledChore
-
Completely shutdown the ScheduleChore, which means we will call cleanup and you should not schedule it again.
- shutdown(E) - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
- shutdown(Thread) - Static method in class org.apache.hadoop.hbase.util.Threads
-
Shutdown passed thread using isAlive and join.
- shutdown(Thread, long) - Static method in class org.apache.hadoop.hbase.util.Threads
-
Shutdown passed thread using isAlive and join.
- shutdown(List<JVMClusterUtil.MasterThread>, List<JVMClusterUtil.RegionServerThread>) - Static method in class org.apache.hadoop.hbase.util.JVMClusterUtil
- shutdown(RpcController, MasterProtos.ShutdownRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- shutdown0() - Method in class org.apache.hadoop.hbase.wal.AbstractFSWALProvider
- shutdown0() - Method in class org.apache.hadoop.hbase.wal.AbstractWALProvider
- shutdown0() - Method in class org.apache.hadoop.hbase.wal.RegionGroupingProvider
- shutdownChore(ScheduledChore) - Method in class org.apache.hadoop.hbase.HBaseServerBase
- shutdownCluster() - Method in class org.apache.hadoop.hbase.master.ServerManager
- org.apache.hadoop.hbase.regionserver.ShutdownHook - Class in org.apache.hadoop.hbase.regionserver
-
Manage regionserver shutdown hooks.
- ShutdownHook() - Constructor for class org.apache.hadoop.hbase.regionserver.ShutdownHook
- org.apache.hadoop.hbase.util.ShutdownHookManager - Class in org.apache.hadoop.hbase.util
-
This class provides ShutdownHookManager shims for HBase to interact with the Hadoop 1.0.x and the Hadoop 2.0+ series.
- ShutdownHookManager() - Constructor for class org.apache.hadoop.hbase.util.ShutdownHookManager
- shutdownMiniCluster() - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Stops mini hbase, zk, and hdfs clusters.
- shutdownMiniDFSCluster() - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Shuts down instance created by call to
HBaseTestingUtility.startMiniDFSCluster(int)
or does nothing. - shutdownMiniHBaseCluster() - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Shutdown HBase mini cluster.Does not shutdown zk or dfs if running.
- shutdownMiniMapReduceCluster() - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Stops the previously started
MiniMRCluster
. - shutdownMiniZKCluster() - Method in class org.apache.hadoop.hbase.HBaseZKTestingUtility
-
Deprecated.Shuts down zk cluster created by call to
HBaseZKTestingUtility.startMiniZKCluster()
or does nothing. - SIMPLE - Enum constant in enum class org.apache.hadoop.hbase.security.AuthMethod
- SIMPLE_AUTHENTICATION - Enum constant in enum class org.apache.hadoop.hbase.client.security.SecurityCapability
- org.apache.hadoop.hbase.util.SimpleByteRange - Class in org.apache.hadoop.hbase.util
-
A read only version of the
ByteRange
. - SimpleByteRange() - Constructor for class org.apache.hadoop.hbase.util.SimpleByteRange
- SimpleByteRange(byte[]) - Constructor for class org.apache.hadoop.hbase.util.SimpleByteRange
-
Create a new
ByteRange
over the providedbytes
. - SimpleByteRange(byte[], int, int) - Constructor for class org.apache.hadoop.hbase.util.SimpleByteRange
-
Create a new
ByteRange
over the providedbytes
. - SimpleByteRange(int) - Constructor for class org.apache.hadoop.hbase.util.SimpleByteRange
- simpleClassName() - Method in enum class org.apache.hadoop.hbase.thrift.ImplType
- simpleMergeOrFlatten(VersionedSegmentsList, String) - Method in class org.apache.hadoop.hbase.regionserver.MemStoreCompactionStrategy
- org.apache.hadoop.hbase.util.SimpleMovingAverage<T> - Class in org.apache.hadoop.hbase.util
-
SMA measure the overall average execution time of a specific method.
- SimpleMovingAverage(String) - Constructor for class org.apache.hadoop.hbase.util.SimpleMovingAverage
- org.apache.hadoop.hbase.util.SimpleMutableByteRange - Class in org.apache.hadoop.hbase.util
-
A basic mutable
ByteRange
implementation. - SimpleMutableByteRange() - Constructor for class org.apache.hadoop.hbase.util.SimpleMutableByteRange
-
Create a new
ByteRange
lacking a backing array and with an undefined viewport. - SimpleMutableByteRange(byte[]) - Constructor for class org.apache.hadoop.hbase.util.SimpleMutableByteRange
-
Create a new
ByteRange
over the providedbytes
. - SimpleMutableByteRange(byte[], int, int) - Constructor for class org.apache.hadoop.hbase.util.SimpleMutableByteRange
-
Create a new
ByteRange
over the providedbytes
. - SimpleMutableByteRange(int) - Constructor for class org.apache.hadoop.hbase.util.SimpleMutableByteRange
-
Create a new
ByteRange
over a new backing array of sizecapacity
. - org.apache.hadoop.hbase.util.SimplePositionedByteRange - Class in org.apache.hadoop.hbase.util
-
Extends the basic
SimpleMutableByteRange
implementation with position support and it is a readonly version. - SimplePositionedByteRange() - Constructor for class org.apache.hadoop.hbase.util.SimplePositionedByteRange
-
Create a new
PositionedByteRange
lacking a backing array and with an undefined viewport. - SimplePositionedByteRange(byte[]) - Constructor for class org.apache.hadoop.hbase.util.SimplePositionedByteRange
-
Create a new
PositionedByteRange
over the providedbytes
. - SimplePositionedByteRange(byte[], int, int) - Constructor for class org.apache.hadoop.hbase.util.SimplePositionedByteRange
-
Create a new
PositionedByteRange
over the providedbytes
. - SimplePositionedByteRange(int) - Constructor for class org.apache.hadoop.hbase.util.SimplePositionedByteRange
-
Create a new
PositionedByteRange
over a new backing array of sizecapacity
. - org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange - Class in org.apache.hadoop.hbase.util
-
Extends the basic
AbstractPositionedByteRange
implementation with position support and it is a mutable version. - SimplePositionedMutableByteRange() - Constructor for class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
-
Create a new
PositionedByteRange
lacking a backing array and with an undefined viewport. - SimplePositionedMutableByteRange(byte[]) - Constructor for class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
-
Create a new
PositionedByteRange
over the providedbytes
. - SimplePositionedMutableByteRange(byte[], int, int) - Constructor for class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
-
Create a new
PositionedByteRange
over the providedbytes
. - SimplePositionedMutableByteRange(int) - Constructor for class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
-
Create a new
PositionedByteRange
over a new backing array of sizecapacity
. - org.apache.hadoop.hbase.ipc.SimpleRpcScheduler - Class in org.apache.hadoop.hbase.ipc
-
The default scheduler.
- SimpleRpcScheduler(Configuration, int, int, int, int, PriorityFunction, Abortable, int) - Constructor for class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
- SimpleRpcScheduler(Configuration, int, int, int, PriorityFunction, int) - Constructor for class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
- org.apache.hadoop.hbase.regionserver.SimpleRpcSchedulerFactory - Class in org.apache.hadoop.hbase.regionserver
-
Constructs a
SimpleRpcScheduler
. - SimpleRpcSchedulerFactory() - Constructor for class org.apache.hadoop.hbase.regionserver.SimpleRpcSchedulerFactory
- org.apache.hadoop.hbase.ipc.SimpleRpcServer - Class in org.apache.hadoop.hbase.ipc
-
Deprecated.
- SimpleRpcServer(Server, String, List<RpcServer.BlockingServiceAndInterface>, InetSocketAddress, Configuration, RpcScheduler, boolean) - Constructor for class org.apache.hadoop.hbase.ipc.SimpleRpcServer
-
Deprecated.Constructs a server listening on the named port and address.
- org.apache.hadoop.hbase.mapreduce.SimpleTotalOrderPartitioner<VALUE> - Class in org.apache.hadoop.hbase.mapreduce
-
A partitioner that takes start and end keys and uses bigdecimal to figure which reduce a key belongs to.
- SimpleTotalOrderPartitioner() - Constructor for class org.apache.hadoop.hbase.mapreduce.SimpleTotalOrderPartitioner
- SINGLE - Enum constant in enum class org.apache.hadoop.hbase.io.hfile.BlockPriority
-
Accessed a single time (used for scan-resistance)
- SINGLE_QUOTE - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
ASCII code for a single quote
- org.apache.hadoop.hbase.nio.SingleByteBuff - Class in org.apache.hadoop.hbase.nio
-
An implementation of ByteBuff where a single BB backs the BBI.
- SingleByteBuff(ByteBuffer) - Constructor for class org.apache.hadoop.hbase.nio.SingleByteBuff
- SingleByteBuff(ByteBuffAllocator.Recycler, ByteBuffer) - Constructor for class org.apache.hadoop.hbase.nio.SingleByteBuff
- org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter - Class in org.apache.hadoop.hbase.filter
-
A
Filter
that checks a single column value, but does not emit the tested column. - SingleColumnValueExcludeFilter(byte[], byte[], CompareOperator, byte[]) - Constructor for class org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter
-
Constructor for binary compare of the value of a single column.
- SingleColumnValueExcludeFilter(byte[], byte[], CompareOperator, ByteArrayComparable) - Constructor for class org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter
-
Constructor for binary compare of the value of a single column.
- SingleColumnValueExcludeFilter(byte[], byte[], CompareOperator, ByteArrayComparable, boolean, boolean) - Constructor for class org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter
-
Constructor for protobuf deserialization only.
- org.apache.hadoop.hbase.filter.SingleColumnValueFilter - Class in org.apache.hadoop.hbase.filter
-
This filter is used to filter cells based on value.
- SingleColumnValueFilter(byte[], byte[], CompareOperator, byte[]) - Constructor for class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
Constructor for binary compare of the value of a single column.
- SingleColumnValueFilter(byte[], byte[], CompareOperator, ByteArrayComparable) - Constructor for class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
Constructor for binary compare of the value of a single column.
- SingleColumnValueFilter(byte[], byte[], CompareOperator, ByteArrayComparable, boolean, boolean) - Constructor for class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
Constructor for protobuf deserialization only.
- org.apache.hadoop.hbase.client.SingleResponse - Class in org.apache.hadoop.hbase.client
-
Class for single action response
- SingleResponse() - Constructor for class org.apache.hadoop.hbase.client.SingleResponse
- org.apache.hadoop.hbase.client.SingleResponse.Entry - Class in org.apache.hadoop.hbase.client
- SingleWriteExampleCallable(Connection, TableName) - Constructor for class org.apache.hadoop.hbase.client.example.MultiThreadedClientExample.SingleWriteExampleCallable
- SinkPeer(ServerName, AsyncRegionServerAdmin) - Constructor for class org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint.SinkPeer
- size - Variable in class org.apache.hadoop.hbase.ipc.ServerCall
- size - Variable in class org.apache.hadoop.hbase.regionserver.Chunk
-
Size of chunk in bytes
- size - Variable in class org.apache.hadoop.hbase.util.ConcatenatedLists
- size() - Method in class org.apache.hadoop.hbase.client.MultiResponse
-
Returns Number of pairs in this container
- size() - Method in class org.apache.hadoop.hbase.client.Mutation
-
Number of KeyValues carried by this Mutation.
- size() - Method in class org.apache.hadoop.hbase.client.Result
-
Returns the size of the underlying Cell []
- size() - Method in interface org.apache.hadoop.hbase.client.RowAccess
-
Returns the number of elements in this list.
- size() - Method in class org.apache.hadoop.hbase.CompoundConfiguration
- size() - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
- size() - Method in class org.apache.hadoop.hbase.favored.FavoredNodesPlan
- size() - Method in class org.apache.hadoop.hbase.filter.FilterList
- size() - Method in class org.apache.hadoop.hbase.filter.FilterListBase
- size() - Method in class org.apache.hadoop.hbase.hbtop.Record
- size() - Method in class org.apache.hadoop.hbase.io.ByteArrayOutputStream
-
Returns The current size of the buffer.
- size() - Method in class org.apache.hadoop.hbase.io.ByteBufferListOutputStream
- size() - Method in class org.apache.hadoop.hbase.io.ByteBufferOutputStream
- size() - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCache
-
Returns the total size of the block cache, in bytes.
- size() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
- size() - Method in class org.apache.hadoop.hbase.io.hfile.HFileInfo
- size() - Method in class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache
- size() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
- size() - Method in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
- size() - Method in class org.apache.hadoop.hbase.io.hfile.TinyLfuBlockCache
- size() - Method in class org.apache.hadoop.hbase.ipc.AdaptiveLifoCoDelCallQueue
- size() - Method in class org.apache.hadoop.hbase.master.DeadServer
- size() - Method in class org.apache.hadoop.hbase.quotas.NoOpRegionSizeStore
- size() - Method in interface org.apache.hadoop.hbase.quotas.RegionSizeStore
-
Returns the number of entries in the store.
- size() - Method in class org.apache.hadoop.hbase.quotas.RegionSizeStoreImpl
- size() - Method in class org.apache.hadoop.hbase.RegionLocations
-
Returns the size of the list even if some of the elements might be null.
- size() - Method in class org.apache.hadoop.hbase.regionserver.CellFlatMap
- size() - Method in class org.apache.hadoop.hbase.regionserver.CellSet
- size() - Method in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
- size() - Method in class org.apache.hadoop.hbase.regionserver.CompactionPipeline
- size() - Method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore
- size() - Method in interface org.apache.hadoop.hbase.regionserver.MemStore
- size() - Method in class org.apache.hadoop.hbase.regionserver.MiniBatchOperationInProgress
-
Returns The number of operations(Mutations) involved in this batch.
- size() - Method in class org.apache.hadoop.hbase.thrift.CallQueue
- size() - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
- size() - Method in class org.apache.hadoop.hbase.util.BoundedPriorityBlockingQueue
- size() - Method in class org.apache.hadoop.hbase.util.ConcatenatedLists
- size() - Method in class org.apache.hadoop.hbase.util.ObjectPool
-
Returns an estimated count of objects kept in the pool.
- size() - Method in interface org.apache.hadoop.hbase.util.PoolMap.Pool
- size() - Method in class org.apache.hadoop.hbase.util.SortedList
- size() - Method in class org.apache.hadoop.hbase.wal.WALEdit
- org.apache.hadoop.hbase.Size - Class in org.apache.hadoop.hbase
-
It is used to represent the size with different units.
- Size(double, Size.Unit) - Constructor for class org.apache.hadoop.hbase.Size
- SIZE - Enum constant in enum class org.apache.hadoop.hbase.hbtop.field.FieldValueType
- SIZE - Enum constant in enum class org.apache.hadoop.hbase.regionserver.wal.WALActionsListener.RollRequestReason
-
The length of the log exceeds the roll size threshold.
- SIZE_LIMIT_REACHED - Enum constant in enum class org.apache.hadoop.hbase.regionserver.ScannerContext.NextState
- SIZE_LIMIT_REACHED_MID_ROW - Enum constant in enum class org.apache.hadoop.hbase.regionserver.ScannerContext.NextState
-
Special case of size limit reached to indicate that the size limit was reached in the middle of a row and thus a partial results was formed
- SIZE_ROLL_REQUESTED - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
- SIZE_ROLL_REQUESTED_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
- SIZE_TO_SPLIT_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.StripeStoreConfig
-
The size the stripe should achieve to be considered for splitting into multiple stripes.
- SIZE_VALUE_NAME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
- org.apache.hadoop.hbase.Size.Unit - Enum Class in org.apache.hadoop.hbase
- sizeAddedPreOperation() - Method in class org.apache.hadoop.hbase.regionserver.AbstractMemStore
- sizeAddedPreOperation() - Method in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
- sizeAddedPreOperation() - Method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore
- org.apache.hadoop.hbase.SizeCachedByteBufferKeyValue - Class in org.apache.hadoop.hbase
-
This Cell is an implementation of
ByteBufferExtendedCell
where the data resides in off heap/ on heap ByteBuffer - SizeCachedByteBufferKeyValue(ByteBuffer, int, int, long, int) - Constructor for class org.apache.hadoop.hbase.SizeCachedByteBufferKeyValue
- SizeCachedByteBufferKeyValue(ByteBuffer, int, int, long, int, short) - Constructor for class org.apache.hadoop.hbase.SizeCachedByteBufferKeyValue
- org.apache.hadoop.hbase.SizeCachedKeyValue - Class in org.apache.hadoop.hbase
-
This class is an extension to KeyValue where rowLen and keyLen are cached.
- SizeCachedKeyValue(byte[], int, int, long, int) - Constructor for class org.apache.hadoop.hbase.SizeCachedKeyValue
- SizeCachedKeyValue(byte[], int, int, long, int, short) - Constructor for class org.apache.hadoop.hbase.SizeCachedKeyValue
- org.apache.hadoop.hbase.SizeCachedNoTagsByteBufferKeyValue - Class in org.apache.hadoop.hbase
-
This Cell is an implementation of
ByteBufferExtendedCell
where the data resides in off heap/ on heap ByteBuffer - SizeCachedNoTagsByteBufferKeyValue(ByteBuffer, int, int, long, int) - Constructor for class org.apache.hadoop.hbase.SizeCachedNoTagsByteBufferKeyValue
- SizeCachedNoTagsByteBufferKeyValue(ByteBuffer, int, int, long, int, short) - Constructor for class org.apache.hadoop.hbase.SizeCachedNoTagsByteBufferKeyValue
- org.apache.hadoop.hbase.SizeCachedNoTagsKeyValue - Class in org.apache.hadoop.hbase
-
This class is an extension to ContentSizeCachedKeyValue where there are no tags in Cell.
- SizeCachedNoTagsKeyValue(byte[], int, int, long, int) - Constructor for class org.apache.hadoop.hbase.SizeCachedNoTagsKeyValue
- SizeCachedNoTagsKeyValue(byte[], int, int, long, int, short) - Constructor for class org.apache.hadoop.hbase.SizeCachedNoTagsKeyValue
- org.apache.hadoop.hbase.io.SizedExtendedCellScanner - Interface in org.apache.hadoop.hbase.io
-
A CellScanner that knows its size in memory in bytes.
- SizeMultiWriter(CellComparator, int, long, byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter.SizeMultiWriter
- sizeOf(byte[]) - Static method in class org.apache.hadoop.hbase.util.ClassSize
-
Calculate the memory consumption (in byte) of a byte array, including the array header and the whole backing byte array.
- SIZEOF_BOOLEAN - Static variable in class org.apache.hadoop.hbase.util.Bytes
-
Size of boolean in bytes
- SIZEOF_BYTE - Static variable in class org.apache.hadoop.hbase.util.Bytes
-
Size of byte in bytes
- SIZEOF_CHAR - Static variable in class org.apache.hadoop.hbase.util.Bytes
-
Size of char in bytes
- SIZEOF_CHUNK_HEADER - Static variable in class org.apache.hadoop.hbase.regionserver.ChunkCreator
- SIZEOF_DOUBLE - Static variable in class org.apache.hadoop.hbase.util.Bytes
-
Size of double in bytes
- SIZEOF_FLOAT - Static variable in class org.apache.hadoop.hbase.util.Bytes
-
Size of float in bytes
- SIZEOF_INT - Static variable in class org.apache.hadoop.hbase.util.Bytes
-
Size of int in bytes
- SIZEOF_LONG - Static variable in class org.apache.hadoop.hbase.util.Bytes
-
Size of long in bytes
- SIZEOF_SHORT - Static variable in class org.apache.hadoop.hbase.util.Bytes
-
Size of short in bytes
- sizeOfByteArray(int) - Static method in class org.apache.hadoop.hbase.util.ClassSize
-
Calculate the memory consumption (in byte) of a part of a byte array, including the array header and the part of the backing byte array.
- SizeStripeFlushRequest(CellComparator, int, long) - Constructor for class org.apache.hadoop.hbase.regionserver.StripeStoreFlusher.SizeStripeFlushRequest
- sizeToString(long) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettings
- skip() - Method in class org.apache.hadoop.hbase.types.StructIterator
-
Bypass the next encoded value.
- skip(int) - Method in class org.apache.hadoop.hbase.nio.ByteBuff
-
Jumps the current position of this ByteBuff by specified length.
- skip(int) - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
Jumps the current position of this MBB by specified length.
- skip(int) - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
- skip(long) - Method in class org.apache.hadoop.hbase.io.ByteBufferInputStream
-
Skips
n
bytes of input from this input stream. - skip(long) - Method in class org.apache.hadoop.hbase.io.ByteBuffInputStream
-
Skips
n
bytes of input from this input stream. - skip(long) - Method in class org.apache.hadoop.hbase.io.FileLink.FileLinkInputStream
- skip(ByteBuffer, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Increment position in buffer.
- skip(PositionedByteRange) - Method in interface org.apache.hadoop.hbase.types.DataType
-
Skip
src
's position forward over one encoded value. - skip(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.FixedLengthWrapper
- skip(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedBytesBase
- skip(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.PBCell
- skip(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawByte
- skip(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawBytes
- skip(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawDouble
- skip(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawFloat
- skip(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawInteger
- skip(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawLong
- skip(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawShort
- skip(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawString
- skip(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.Struct
- skip(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.TerminatedWrapper
-
Skip
src
's position forward over one encoded value. - skip(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Skip
buff
's position forward over one encoded value. - SKIP - Enum constant in enum class org.apache.hadoop.hbase.client.RequestController.ReturnCode
-
Skip current row.
- SKIP - Enum constant in enum class org.apache.hadoop.hbase.filter.Filter.ReturnCode
-
Skip this Cell
- SKIP - Enum constant in enum class org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher.MatchCode
-
Do not include KeyValue in the returned result
- SKIP_ARRAY - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
SKIP Array
- SKIP_BUFFER - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
- SKIP_EMPTY_COLUMNS - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv
- SKIP_LINES_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv
- SKIP_LOAD_DUPLICATE_TABLE_COPROCESSOR - Static variable in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
- SKIP_LOGIN_KEY - Static variable in class org.apache.hadoop.hbase.rest.RESTServer
- SKIP_RESET_SEQ_ID - Static variable in class org.apache.hadoop.hbase.regionserver.HStoreFile
-
Key for skipping resetting sequence id in metadata.
- SKIP_WAL - Enum constant in enum class org.apache.hadoop.hbase.client.Durability
-
Do not write the Mutation to the WAL
- org.apache.hadoop.hbase.filter.SkipFilter - Class in org.apache.hadoop.hbase.filter
-
A wrapper filter that filters an entire row if any of the Cell checks do not pass.
- SkipFilter(Filter) - Constructor for class org.apache.hadoop.hbase.filter.SkipFilter
- SKIPFLUSH - Enum constant in enum class org.apache.hadoop.hbase.client.SnapshotType
- skipKVsNewerThanReadpoint() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
- skipRegionManagementAction(String) - Method in class org.apache.hadoop.hbase.master.HMaster
-
Checks master state before initiating action over region topology.
- skipRegionManagementAction(String) - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Checks master state before initiating action over region topology.
- skipRemoteWAL(boolean) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
- skipRemoteWAL(boolean) - Method in interface org.apache.hadoop.hbase.wal.WAL
-
Tell the WAL that when creating new writer you can skip creating the remote writer.
- skipSleepCycle() - Method in class org.apache.hadoop.hbase.util.Sleeper
-
If currently asleep, stops sleeping; if not asleep, will skip the next sleep cycle.
- skipStoreFileRangeCheck(String) - Method in class org.apache.hadoop.hbase.regionserver.RegionSplitPolicy
-
In
HRegionFileSystem#splitStoreFile(org.apache.hadoop.hbase.client.RegionInfo, String, HStoreFile, byte[], boolean, RegionSplitPolicy)
we are not creating the split reference if split row does not lie inside the StoreFile range. - skipTo(long) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractProtobufWALReader
-
Skip to the given position.
- skipTo(long) - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufWALStreamReader
- skipTo(long) - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufWALTailingReader
- sleep() - Method in class org.apache.hadoop.hbase.util.Sleeper
-
Sleep for period.
- sleep(long) - Method in class org.apache.hadoop.hbase.util.Sleeper
- sleep(long) - Static method in class org.apache.hadoop.hbase.util.Threads
-
If interrupted, just prints out the interrupt on STDOUT, resets interrupt and returns
- SLEEP_DELTA_NS - Static variable in class org.apache.hadoop.hbase.client.ConnectionUtils
- SLEEP_INTERVAL_KEY - Static variable in class org.apache.hadoop.hbase.namequeues.WALEventTrackerTableAccessor
- sleeper - Variable in class org.apache.hadoop.hbase.HBaseServerBase
- org.apache.hadoop.hbase.util.Sleeper - Class in org.apache.hadoop.hbase.util
-
Sleeper for current thread.
- Sleeper(int, Stoppable) - Constructor for class org.apache.hadoop.hbase.util.Sleeper
- sleepForMs - Variable in class org.apache.hadoop.hbase.util.compaction.MajorCompactor
- sleepForRetries(String, long, int, int) - Static method in class org.apache.hadoop.hbase.replication.ReplicationUtils
-
Do the sleeping logic
- sleepUntilNextRetry() - Method in class org.apache.hadoop.hbase.util.RetryCounter
-
Sleep for a back off time as supplied by the backoff policy, and increases the attempts
- sleepWithoutInterrupt(long) - Static method in class org.apache.hadoop.hbase.util.Threads
-
Sleeps for the given amount of time even if interrupted.
- slice() - Method in class org.apache.hadoop.hbase.nio.ByteBuff
-
Returns an ByteBuff which is a sliced version of this ByteBuff.
- slice() - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
Returns an MBB which is a sliced version of this MBB.
- slice() - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
- SLOW_APPEND_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
- SLOW_APPEND_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
- SLOW_APPEND_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- SLOW_APPEND_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- SLOW_DELETE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- SLOW_DELETE_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- SLOW_FS_READS_DESC - Static variable in interface org.apache.hadoop.hbase.io.MetricsIOSource
- SLOW_FS_READS_KEY - Static variable in interface org.apache.hadoop.hbase.io.MetricsIOSource
- SLOW_GET_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- SLOW_GET_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- SLOW_INCREMENT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- SLOW_INCREMENT_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- SLOW_LOG - Enum constant in enum class org.apache.hadoop.hbase.client.LogQueryFilter.Type
-
Deprecated.
- SLOW_LOG - Enum constant in enum class org.apache.hadoop.hbase.namequeues.NamedQueuePayload.NamedQueueEvent
- SLOW_LOG_BUFFER_ENABLED_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
- SLOW_LOG_EVENT - Static variable in class org.apache.hadoop.hbase.namequeues.RpcLogDetails
- SLOW_LOG_SCAN_PAYLOAD_ENABLED - Static variable in class org.apache.hadoop.hbase.HConstants
- SLOW_LOG_SCAN_PAYLOAD_ENABLED_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
- SLOW_LOG_SYS_TABLE_CHORE_DURATION_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
Deprecated.
- SLOW_LOG_SYS_TABLE_ENABLED_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
- SLOW_LOG_TABLE_NAME - Static variable in class org.apache.hadoop.hbase.slowlog.SlowLogTableAccessor
-
hbase:slowlog table name - can be enabled with config - hbase.regionserver.slowlog.systable.enabled
- SLOW_METRIC_TIME - Static variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
- SLOW_PUT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- SLOW_PUT_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- SLOW_RESPONSE_NANO_SEC - Static variable in class org.apache.hadoop.hbase.thrift.ThriftMetrics
- SLOW_SYNC - Enum constant in enum class org.apache.hadoop.hbase.regionserver.wal.WALActionsListener.RollRequestReason
-
Too much time spent waiting for sync.
- SLOW_SYNC_ROLL_INTERVAL_MS - Static variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
- SLOW_SYNC_ROLL_REQUESTED - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
- SLOW_SYNC_ROLL_REQUESTED_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
- SLOW_SYNC_ROLL_THRESHOLD - Static variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
- SLOW_SYNC_TIME_MS - Static variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
- SLOW_THRIFT_CALL_KEY - Static variable in interface org.apache.hadoop.hbase.thrift.MetricsThriftServerSource
- SLOWLOG_INFO_FAMILY - Static variable in class org.apache.hadoop.hbase.HConstants
-
The slowlog info family
- org.apache.hadoop.hbase.client.SlowLogParams - Class in org.apache.hadoop.hbase.client
-
SlowLog params object that contains detailed info as params and region name : to be used for filter purpose
- SlowLogParams(String) - Constructor for class org.apache.hadoop.hbase.client.SlowLogParams
- SlowLogParams(String, String) - Constructor for class org.apache.hadoop.hbase.client.SlowLogParams
- SlowLogParams(String, String, ClientProtos.Scan) - Constructor for class org.apache.hadoop.hbase.client.SlowLogParams
- org.apache.hadoop.hbase.namequeues.SlowLogPersistentService - Class in org.apache.hadoop.hbase.namequeues
-
Persistent service provider for Slow/LargeLog events
- SlowLogPersistentService(Configuration) - Constructor for class org.apache.hadoop.hbase.namequeues.SlowLogPersistentService
- org.apache.hadoop.hbase.namequeues.impl.SlowLogQueueService - Class in org.apache.hadoop.hbase.namequeues.impl
-
In-memory Queue service provider for Slow/LargeLog events
- SlowLogQueueService(Configuration) - Constructor for class org.apache.hadoop.hbase.namequeues.impl.SlowLogQueueService
- org.apache.hadoop.hbase.slowlog.SlowLogTableAccessor - Class in org.apache.hadoop.hbase.slowlog
-
Slowlog Accessor to record slow/large RPC log identified at each RegionServer RpcServer level.
- SlowLogTableAccessor() - Constructor for class org.apache.hadoop.hbase.slowlog.SlowLogTableAccessor
- slowMetricTime - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
- slowResponseTime - Variable in class org.apache.hadoop.hbase.thrift.ThriftMetrics
- slowSyncCheckInterval - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
- slowSyncCount - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
- slowSyncNs - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
The slow sync will be logged; the very slow sync will cause the WAL to be rolled.
- slowSyncRollThreshold - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
- SMALL_COMPACTION_QUEUE_LENGTH - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- SMALL_COMPACTION_QUEUE_LENGTH_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- SMALL_COMPACTION_THREADS - Static variable in class org.apache.hadoop.hbase.regionserver.CompactSplit
- SMALL_COMPACTION_THREADS_DEFAULT - Static variable in class org.apache.hadoop.hbase.regionserver.CompactSplit
- SNAPPY - Enum constant in enum class org.apache.hadoop.hbase.io.compress.Compression.Algorithm
- SNAPPY_CODEC_CLASS_DEFAULT - Static variable in class org.apache.hadoop.hbase.io.compress.Compression
- SNAPPY_CODEC_CLASS_KEY - Static variable in class org.apache.hadoop.hbase.io.compress.Compression
- snapshot - Variable in class org.apache.hadoop.hbase.regionserver.AbstractMemStore
- snapshot() - Method in interface org.apache.hadoop.hbase.metrics.Histogram
-
Snapshot the current values in the Histogram
- snapshot() - Method in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
-
Push the current active memstore segment into the pipeline and create a snapshot of the tail of current compaction pipeline Snapshot must be cleared by call to
AbstractMemStore.clearSnapshot(long)
. - snapshot() - Method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore
-
Creates a snapshot of the current memstore.
- snapshot() - Method in interface org.apache.hadoop.hbase.regionserver.MemStore
-
Creates a snapshot of the current memstore.
- snapshot(String, TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Take a snapshot for the given table.
- snapshot(String, TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Take a snapshot for the given table.
- snapshot(String, TableName, Map<String, Object>) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Create typed snapshot of the table.
- snapshot(String, TableName, SnapshotType) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Create typed snapshot of the table.
- snapshot(String, TableName, SnapshotType) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Create typed snapshot of the table.
- snapshot(String, TableName, SnapshotType, Map<String, Object>) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Create typed snapshot of the table.
- snapshot(SnapshotDescription) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Take a snapshot and wait for the server to complete that snapshot (blocking).
- snapshot(SnapshotDescription) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Take a snapshot and wait for the server to complete that snapshot asynchronously.
- snapshot(RpcController, MasterProtos.SnapshotRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
Triggers an asynchronous attempt to take a snapshot.
- org.apache.hadoop.hbase.metrics.Snapshot - Interface in org.apache.hadoop.hbase.metrics
-
A statictical sample of histogram values.
- SNAPSHOT - Enum constant in enum class org.apache.hadoop.hbase.backup.BackupInfo.BackupPhase
- SNAPSHOT - Enum constant in enum class org.apache.hadoop.hbase.regionserver.Region.Operation
- SNAPSHOT_CLONE_TIME_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsSnapshotSource
- SNAPSHOT_CLONE_TIME_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsSnapshotSource
- SNAPSHOT_CORRUPTED_FILE - Static variable in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
- SNAPSHOT_DIR_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
-
Name of the directory to store all snapshots.
- SNAPSHOT_INPUTFORMAT_LOCALITY_BY_REGION_LOCATION - Static variable in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl
-
Whether to calculate the Snapshot region location by region location from meta.
- SNAPSHOT_INPUTFORMAT_LOCALITY_BY_REGION_LOCATION_DEFAULT - Static variable in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl
- SNAPSHOT_INPUTFORMAT_LOCALITY_ENABLED_DEFAULT - Static variable in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl
- SNAPSHOT_INPUTFORMAT_LOCALITY_ENABLED_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl
-
Whether to calculate the block location for splits.
- SNAPSHOT_INPUTFORMAT_ROW_LIMIT_PER_INPUTSPLIT - Static variable in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl
-
In some scenario, scan limited rows on each InputSplit for sampling data extraction
- SNAPSHOT_INPUTFORMAT_SCAN_METRICS_ENABLED - Static variable in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl
-
Whether to enable scan metrics on Scan, default to true
- SNAPSHOT_INPUTFORMAT_SCAN_METRICS_ENABLED_DEFAULT - Static variable in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl
- SNAPSHOT_INPUTFORMAT_SCANNER_READTYPE - Static variable in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl
-
The
Scan.ReadType
which should be set on theScan
to read the HBase Snapshot, default STREAM. - SNAPSHOT_INPUTFORMAT_SCANNER_READTYPE_DEFAULT - Static variable in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl
- SNAPSHOT_LAYOUT_VERSION - Static variable in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
Version of the fs layout for a snapshot.
- SNAPSHOT_MANIFEST_PREFIX - Static variable in class org.apache.hadoop.hbase.snapshot.SnapshotManifestV2
- SNAPSHOT_MANIFEST_SIZE_LIMIT_CONF_KEY - Static variable in class org.apache.hadoop.hbase.snapshot.SnapshotManifest
- SNAPSHOT_NOTIFIER_DEFAULT - Static variable in class org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshotNotifierFactory
- SNAPSHOT_NOTIFIER_KEY - Static variable in class org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshotNotifierFactory
- SNAPSHOT_OBSERVER_CHORE_TIME_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterQuotaSource
- SNAPSHOT_OBSERVER_CHORE_TIME_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterQuotaSource
- SNAPSHOT_OBSERVER_FETCH_TIME_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterQuotaSource
- SNAPSHOT_OBSERVER_FETCH_TIME_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterQuotaSource
- SNAPSHOT_OBSERVER_SIZE_COMPUTATION_TIME_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterQuotaSource
- SNAPSHOT_OBSERVER_SIZE_COMPUTATION_TIME_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterQuotaSource
- SNAPSHOT_RESTORE_FAILSAFE_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
- SNAPSHOT_RESTORE_TAKE_FAILSAFE_SNAPSHOT - Static variable in class org.apache.hadoop.hbase.HConstants
- SNAPSHOT_RESTORE_TIME_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsSnapshotSource
- SNAPSHOT_RESTORE_TIME_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsSnapshotSource
- SNAPSHOT_TIME_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsSnapshotSource
- SNAPSHOT_TIME_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsSnapshotSource
- SNAPSHOT_TMP_DIR_NAME - Static variable in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
Temporary directory under the snapshot directory to store in-progress snapshots
- SNAPSHOT_TO_SCANS_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.MultiTableSnapshotInputFormatImpl
- SNAPSHOT_WORKING_DIR - Static variable in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
The configuration property that determines the filepath of the snapshot base working directory
- snapshotAsync(SnapshotDescription) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Take a snapshot without waiting for the server to complete that snapshot (asynchronous).
- snapshotCleanupSwitch(boolean, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Turn on or off the auto snapshot cleanup based on TTL.
- snapshotCleanupSwitch(boolean, boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Turn on or off the auto snapshot cleanup based on TTL.
- snapshotCleanupZNode - 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.
- SNAPSHOTCOPY - Enum constant in enum class org.apache.hadoop.hbase.backup.BackupInfo.BackupPhase
- org.apache.hadoop.hbase.snapshot.SnapshotCreationException - Exception in org.apache.hadoop.hbase.snapshot
-
Thrown when a snapshot could not be created due to a server-side error when taking the snapshot.
- SnapshotCreationException(String) - Constructor for exception org.apache.hadoop.hbase.snapshot.SnapshotCreationException
-
Used internally by the RPC engine to pass the exception back to the client.
- SnapshotCreationException(String, Throwable, SnapshotDescription) - Constructor for exception org.apache.hadoop.hbase.snapshot.SnapshotCreationException
-
Failure to create the specified snapshot due to an external cause.
- SnapshotCreationException(String, SnapshotDescription) - Constructor for exception org.apache.hadoop.hbase.snapshot.SnapshotCreationException
-
Failure to create the specified snapshot.
- org.apache.hadoop.hbase.client.SnapshotDescription - Class in org.apache.hadoop.hbase.client
-
The POJO equivalent of HBaseProtos.SnapshotDescription
- SnapshotDescription(String) - Constructor for class org.apache.hadoop.hbase.client.SnapshotDescription
- SnapshotDescription(String, TableName) - Constructor for class org.apache.hadoop.hbase.client.SnapshotDescription
- SnapshotDescription(String, TableName, SnapshotType) - Constructor for class org.apache.hadoop.hbase.client.SnapshotDescription
- SnapshotDescription(String, TableName, SnapshotType, String) - Constructor for class org.apache.hadoop.hbase.client.SnapshotDescription
- SnapshotDescription(String, TableName, SnapshotType, String, long, int) - Constructor for class org.apache.hadoop.hbase.client.SnapshotDescription
-
Deprecated.since 2.3.0 and will be removed in 4.0.0. Use
SnapshotDescription(String, TableName, SnapshotType, String, long, int, Map)
- SnapshotDescription(String, TableName, SnapshotType, String, long, int, Map<String, Object>) - Constructor for class org.apache.hadoop.hbase.client.SnapshotDescription
-
SnapshotDescription Parameterized Constructor
- SnapshotDescription(String, TableName, SnapshotType, Map<String, Object>) - Constructor for class org.apache.hadoop.hbase.client.SnapshotDescription
-
SnapshotDescription Parameterized Constructor
- org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils - Class in org.apache.hadoop.hbase.snapshot
-
Utility class to help manage
SnapshotDesriptions
. - org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils.CompletedSnaphotDirectoriesFilter - Class in org.apache.hadoop.hbase.snapshot
-
Filter that only accepts completed snapshot directories
- org.apache.hadoop.hbase.snapshot.SnapshotDoesNotExistException - Exception in org.apache.hadoop.hbase.snapshot
-
Thrown when the server is looking for a snapshot, but can't find the snapshot on the filesystem.
- SnapshotDoesNotExistException(String) - Constructor for exception org.apache.hadoop.hbase.snapshot.SnapshotDoesNotExistException
- SnapshotDoesNotExistException(SnapshotDescription) - Constructor for exception org.apache.hadoop.hbase.snapshot.SnapshotDoesNotExistException
- org.apache.hadoop.hbase.snapshot.SnapshotExistsException - Exception in org.apache.hadoop.hbase.snapshot
-
Thrown when a snapshot exists, but should not.
- SnapshotExistsException(String) - Constructor for exception org.apache.hadoop.hbase.snapshot.SnapshotExistsException
-
Failure due to the snapshot already existing.
- SnapshotExistsException(String, SnapshotDescription) - Constructor for exception org.apache.hadoop.hbase.snapshot.SnapshotExistsException
-
Failure due to the snapshot already existing.
- snapshotId - Variable in class org.apache.hadoop.hbase.regionserver.AbstractMemStore
- org.apache.hadoop.hbase.snapshot.SnapshotInfo - Class in org.apache.hadoop.hbase.snapshot
-
Tool for dumping snapshot information.
- SnapshotInfo() - Constructor for class org.apache.hadoop.hbase.snapshot.SnapshotInfo
- SNAPSHOTINFO_FILE - Static variable in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
The file contains the snapshot basic information and it is under the directory of a snapshot.
- org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats - Class in org.apache.hadoop.hbase.snapshot
-
Statistics about the snapshot How many store files and logs are in the archive How many store files and logs are shared with the table Total store files and logs size and shared amount
- org.apache.hadoop.hbase.snapshot.SnapshotManifest - Class in org.apache.hadoop.hbase.snapshot
-
Utility class to help read/write the Snapshot Manifest.
- org.apache.hadoop.hbase.snapshot.SnapshotManifestV1 - Class in org.apache.hadoop.hbase.snapshot
-
DO NOT USE DIRECTLY.
- org.apache.hadoop.hbase.snapshot.SnapshotManifestV2 - Class in org.apache.hadoop.hbase.snapshot
-
DO NOT USE DIRECTLY.
- org.apache.hadoop.hbase.master.SnapshotOfRegionAssignmentFromMeta - Class in org.apache.hadoop.hbase.master
-
Used internally for reading meta and constructing datastructures that are then queried, for things like regions to regionservers, table to regions, etc.
- SnapshotOfRegionAssignmentFromMeta(Connection) - Constructor for class org.apache.hadoop.hbase.master.SnapshotOfRegionAssignmentFromMeta
- SnapshotOfRegionAssignmentFromMeta(Connection, Set<TableName>, boolean) - Constructor for class org.apache.hadoop.hbase.master.SnapshotOfRegionAssignmentFromMeta
- org.apache.hadoop.hbase.quotas.SnapshotQuotaObserverChore - Class in org.apache.hadoop.hbase.quotas
-
A Master-invoked
Chore
that computes the size of each snapshot which was created from a table which has a space quota. - SnapshotQuotaObserverChore(HMaster, MetricsMaster) - Constructor for class org.apache.hadoop.hbase.quotas.SnapshotQuotaObserverChore
- org.apache.hadoop.hbase.snapshot.SnapshotReferenceUtil - Class in org.apache.hadoop.hbase.snapshot
-
Utility methods for interacting with the snapshot referenced files.
- org.apache.hadoop.hbase.snapshot.SnapshotReferenceUtil.SnapshotVisitor - Interface in org.apache.hadoop.hbase.snapshot
- org.apache.hadoop.hbase.snapshot.SnapshotReferenceUtil.StoreFileVisitor - Interface in org.apache.hadoop.hbase.snapshot
- org.apache.hadoop.hbase.regionserver.SnapshotRegionCallable - Class in org.apache.hadoop.hbase.regionserver
- SnapshotRegionCallable() - Constructor for class org.apache.hadoop.hbase.regionserver.SnapshotRegionCallable
- snapshotRegionSizes() - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
- org.apache.hadoop.hbase.regionserver.SnapshotSegmentScanner - Class in org.apache.hadoop.hbase.regionserver
-
A basic SegmentScanner used against an ImmutableScanner snapshot Used flushing where we do a single pass, no reverse scanning or inserts happening.
- SnapshotSegmentScanner(ImmutableSegment) - Constructor for class org.apache.hadoop.hbase.regionserver.SnapshotSegmentScanner
- org.apache.hadoop.hbase.master.SnapshotSentinel - Interface in org.apache.hadoop.hbase.master
-
Watch the current snapshot under process
- org.apache.hadoop.hbase.snapshot.SnapshotTTLExpiredException - Exception in org.apache.hadoop.hbase.snapshot
-
Thrown when a snapshot could not be restored/cloned because the ttl for snapshot has already expired
- SnapshotTTLExpiredException(String) - Constructor for exception org.apache.hadoop.hbase.snapshot.SnapshotTTLExpiredException
-
Failure when the ttl for snapshot has already expired.
- SnapshotTTLExpiredException(SnapshotDescription) - Constructor for exception org.apache.hadoop.hbase.snapshot.SnapshotTTLExpiredException
-
Failure when the ttl for snapshot has already expired.
- org.apache.hadoop.hbase.client.SnapshotType - Enum Class in org.apache.hadoop.hbase.client
-
POJO representing the snapshot type
- org.apache.hadoop.hbase.regionserver.SnapshotVerifyCallable - Class in org.apache.hadoop.hbase.regionserver
- SnapshotVerifyCallable() - Constructor for class org.apache.hadoop.hbase.regionserver.SnapshotVerifyCallable
- SOCKET_RETRY_WAIT_MS - Static variable in class org.apache.hadoop.hbase.HConstants
-
The delay when re-trying a socket operation in a loop (HBASE-4712)
- SOCKET_TIMEOUT_CONNECT - Static variable in interface org.apache.hadoop.hbase.ipc.RpcClient
- SOCKET_TIMEOUT_READ - Static variable in interface org.apache.hadoop.hbase.ipc.RpcClient
-
How long we wait when we wait for an answer.
- SOCKET_TIMEOUT_WRITE - Static variable in interface org.apache.hadoop.hbase.ipc.RpcClient
- socketFactory - Variable in class org.apache.hadoop.hbase.ipc.BlockingRpcClient
- socketSendBufferSize - Variable in class org.apache.hadoop.hbase.ipc.SimpleRpcServer
-
Deprecated.
- SOFT - Enum constant in enum class org.apache.hadoop.hbase.util.IdReadWriteLockWithObjectPool.ReferenceType
- SOFT_LIMIT_PERCENTAGE - Static variable in class org.apache.hadoop.hbase.regionserver.regionreplication.RegionReplicationBufferManager
- SOFT_LIMIT_PERCENTAGE_DEFAULT - Static variable in class org.apache.hadoop.hbase.regionserver.regionreplication.RegionReplicationBufferManager
- org.apache.hadoop.hbase.util.SoftObjectPool<K,
V> - Class in org.apache.hadoop.hbase.util -
A
SoftReference
based shared object pool. - SoftObjectPool(ObjectPool.ObjectFactory<K, V>) - Constructor for class org.apache.hadoop.hbase.util.SoftObjectPool
- SoftObjectPool(ObjectPool.ObjectFactory<K, V>, int) - Constructor for class org.apache.hadoop.hbase.util.SoftObjectPool
- SoftObjectPool(ObjectPool.ObjectFactory<K, V>, int, int) - Constructor for class org.apache.hadoop.hbase.util.SoftObjectPool
- solve() - Method in class org.apache.hadoop.hbase.util.MunkresAssignment
-
Get the optimal assignments.
- sortAndMerge(List<MultiRowRangeFilter.RowRange>) - Static method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter
-
sort the ranges and if the ranges with overlap, then merge them.
- org.apache.hadoop.hbase.util.SortedList<E> - Class in org.apache.hadoop.hbase.util
-
Simple sorted list implementation that uses
ArrayList
as the underlying collection so we can support RandomAccess. - SortedList(Collection<? extends E>, Comparator<? super E>) - Constructor for class org.apache.hadoop.hbase.util.SortedList
-
Constructs a list containing the elements of the given collection, in the order returned by the collection's iterator, that will be sorted with the given comparator.
- SortedList(Comparator<? super E>) - Constructor for class org.apache.hadoop.hbase.util.SortedList
-
Constructs an empty list with the default initial capacity that will be sorted using the given comparator.
- sortedPrefixes - Variable in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
- source - Variable in class org.apache.hadoop.hbase.thrift.ThriftMetrics
- SOURCEMISSINGCELLS - Enum constant in enum class org.apache.hadoop.hbase.mapreduce.SyncTable.SyncMapper.Counter
- SOURCEMISSINGROWS - Enum constant in enum class org.apache.hadoop.hbase.mapreduce.SyncTable.SyncMapper.Counter
- sourceScanner - Variable in class org.apache.hadoop.hbase.regionserver.AbstractMultiFileWriter
-
Source scanner that is tracking KV count; may be null if source is not StoreScanner
- SPACE - Enum constant in enum class org.apache.hadoop.hbase.quotas.QuotaType
- SPACE_QUOTA_REFRESHER_CHORE_TIME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerQuotaSource
- org.apache.hadoop.hbase.quotas.SpaceLimitingException - Exception in org.apache.hadoop.hbase.quotas
-
An Exception that is thrown when a space quota is in violation.
- SpaceLimitingException(String) - Constructor for exception org.apache.hadoop.hbase.quotas.SpaceLimitingException
- SpaceLimitingException(String, String) - Constructor for exception org.apache.hadoop.hbase.quotas.SpaceLimitingException
- SpaceLimitingException(String, String, Throwable) - Constructor for exception org.apache.hadoop.hbase.quotas.SpaceLimitingException
- org.apache.hadoop.hbase.quotas.SpaceQuotaRefresherChore - Class in org.apache.hadoop.hbase.quotas
-
A
ScheduledChore
which periodically updates theRegionServerSpaceQuotaManager
with information from the hbase:quota. - SpaceQuotaRefresherChore(RegionServerSpaceQuotaManager, Connection) - Constructor for class org.apache.hadoop.hbase.quotas.SpaceQuotaRefresherChore
- org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot - Class in org.apache.hadoop.hbase.quotas
-
A point-in-time view of a space quota on a table.
- SpaceQuotaSnapshot(SpaceQuotaSnapshot.SpaceQuotaStatus, long, long) - Constructor for class org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot
- org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot.SpaceQuotaStatus - Class in org.apache.hadoop.hbase.quotas
-
Encapsulates the state of a quota on a table.
- org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshotNotifier - Interface in org.apache.hadoop.hbase.quotas
-
An interface which abstract away the action taken to enable or disable a space quota violation policy across the HBase cluster.
- org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshotNotifierFactory - Class in org.apache.hadoop.hbase.quotas
-
Factory for creating
SpaceQuotaSnapshotNotifier
implementations. - org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshotView - Interface in org.apache.hadoop.hbase.quotas
-
A point-in-time view of a space quota on a table, read only.
- org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshotView.SpaceQuotaStatusView - Interface in org.apache.hadoop.hbase.quotas
-
Encapsulates the state of a quota on a table.
- SpaceQuotaStatus(SpaceViolationPolicy) - Constructor for class org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot.SpaceQuotaStatus
-
Constructs a
SpaceQuotaSnapshot
which is in violation of the providedpolicy
. - org.apache.hadoop.hbase.quotas.SpaceViolationPolicy - Enum Class in org.apache.hadoop.hbase.quotas
-
Enumeration that represents the action HBase will take when a space quota is violated.
- org.apache.hadoop.hbase.quotas.SpaceViolationPolicyEnforcement - Interface in org.apache.hadoop.hbase.quotas
-
RegionServer implementation of
SpaceViolationPolicy
. - org.apache.hadoop.hbase.quotas.SpaceViolationPolicyEnforcementFactory - Class in org.apache.hadoop.hbase.quotas
-
A factory class for instantiating
SpaceViolationPolicyEnforcement
instances. - SPARK - Static variable in class org.apache.hadoop.hbase.HBaseInterfaceAudience
- SPECIAL_RECOVERED_EDITS_DIR - Static variable in class org.apache.hadoop.hbase.regionserver.HRegion
-
This is for for using HRegion as a local storage, where we may put the recovered edits in a special place.
- SPECIFIC_WRITE_THREAD - Static variable in interface org.apache.hadoop.hbase.ipc.RpcClient
- split(byte[], byte[]) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.NumberStringSplit
- split(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.util.RegionSplitter.SplitAlgorithm
-
Split a pre-existing region into 2 regions.
- split(byte[], byte[]) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.UniformSplit
- split(byte[], byte[], boolean, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Split passed range.
- split(byte[], byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Split passed range.
- split(byte[], byte[], int, boolean) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.NumberStringSplit
- split(byte[], byte[], int, boolean) - Method in interface org.apache.hadoop.hbase.util.RegionSplitter.SplitAlgorithm
-
Some MapReduce jobs may want to run multiple mappers per region, this is intended for such usecase.
- split(byte[], byte[], int, boolean) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.UniformSplit
- split(int) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.NumberStringSplit
- split(int) - Method in interface org.apache.hadoop.hbase.util.RegionSplitter.SplitAlgorithm
-
Split an entire table.
- split(int) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.UniformSplit
- split(Path, Path, Path, FileSystem, Configuration, WALFactory) - Static method in class org.apache.hadoop.hbase.wal.WALSplitter
-
Split a folder of WAL files.
- split(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Split a table.
- split(TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Split a table.
- split(TableName, byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Split a table.
- split(TableName, byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Split a table.
- SPLIT - Enum constant in enum class org.apache.hadoop.hbase.client.MasterSwitchType
- SPLIT - Enum constant in enum class org.apache.hadoop.hbase.master.RegionState.State
- SPLIT_ALGO - Static variable in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl
-
For MapReduce jobs running multiple mappers per region, determines what split algorithm we should be using to find split points for scanners.
- SPLIT_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 split enabled.
- SPLIT_IGNORE_BLOCKING_ENABLED_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.HRegion
-
Config for allow split when file count greater than the configured blocking file count
- SPLIT_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- SPLIT_LOGDIR_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
-
Used to construct the name of the splitlog directory for a region server
- SPLIT_METRIC_PREFIX - Static variable in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
- SPLIT_PARTS_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.StripeStoreConfig
-
The target count of new stripes to produce when splitting a stripe.
- SPLIT_PLAN_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
- SPLIT_PLAN_COUNT_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
- SPLIT_POLICY - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
- SPLIT_QUEUE_LENGTH - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- SPLIT_QUEUE_LENGTH_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- SPLIT_REGION - Enum constant in enum class org.apache.hadoop.hbase.regionserver.Region.Operation
- SPLIT_REQUEST_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- SPLIT_REQUEST_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- SPLIT_SIZE_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterFileSystemSource
- SPLIT_SIZE_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterFileSystemSource
- SPLIT_SKIP_ERRORS_DEFAULT - Static variable in class org.apache.hadoop.hbase.wal.WALSplitter
-
By default we retry errors in splitting, rather than skipping.
- SPLIT_SKIP_ERRORS_KEY - Static variable in class org.apache.hadoop.hbase.wal.WALSplitter
- SPLIT_SUCCESS_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- SPLIT_SUCCESS_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- SPLIT_THREADS - Static variable in class org.apache.hadoop.hbase.regionserver.CompactSplit
- SPLIT_THREADS_DEFAULT - Static variable in class org.apache.hadoop.hbase.regionserver.CompactSplit
- SPLIT_TIME_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterFileSystemSource
- SPLIT_TIME_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterFileSystemSource
- SPLIT_WAL_BUFFER_SIZE - Static variable in class org.apache.hadoop.hbase.wal.WALSplitter
- SPLIT_WAL_WRITER_THREADS - Static variable in class org.apache.hadoop.hbase.wal.WALSplitter
- SPLIT_WRITER_CREATION_BOUNDED - Static variable in class org.apache.hadoop.hbase.wal.WALSplitter
-
True if we are to run with bounded amount of writers rather than let the count blossom.
- split2(BigInteger, BigInteger) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.NumberStringSplit
-
Divide 2 numbers in half (for split algorithm)
- SPLITA_QUALIFIER - Static variable in class org.apache.hadoop.hbase.HConstants
-
The lower-half split region column qualifier
- SPLITA_QUALIFIER_STR - Static variable in class org.apache.hadoop.hbase.HConstants
-
The lower-half split region column qualifier string.
- SPLITB_QUALIFIER - Static variable in class org.apache.hadoop.hbase.HConstants
-
The upper-half split region column qualifier
- SPLITB_QUALIFIER_STR - Static variable in class org.apache.hadoop.hbase.HConstants
-
The upper-half split region column qualifier String.
- splitColonSeparated(String, int, int) - Method in class org.apache.hadoop.hbase.util.LoadTestTool
- splitKerberosName(String) - Static method in class org.apache.hadoop.hbase.security.SaslUtil
-
Splitting fully qualified Kerberos name into parts
- splitkey - Variable in class org.apache.hadoop.hbase.io.HalfStoreFileReader
- splitLog(Set<ServerName>) - Method in class org.apache.hadoop.hbase.master.MasterWalManager
- splitLog(Set<ServerName>, PathFilter) - Method in class org.apache.hadoop.hbase.master.MasterWalManager
-
This method is the base split method that splits WAL files matching a filter.
- splitLog(ServerName) - Method in class org.apache.hadoop.hbase.master.MasterWalManager
- org.apache.hadoop.hbase.SplitLogCounters - Class in org.apache.hadoop.hbase
-
Deprecated.since 2.4.0 and in 3.0.0, to be removed in 4.0.0, replaced by procedure-based distributed WAL splitter, see SplitWALManager
- splitLogDistributed(List<Path>) - Method in class org.apache.hadoop.hbase.master.SplitLogManager
-
Deprecated.The caller will block until all the log files of the given region server have been processed - successfully split or an error is encountered - by an available worker region server.
- splitLogDistributed(Set<ServerName>, List<Path>, PathFilter) - Method in class org.apache.hadoop.hbase.master.SplitLogManager
-
Deprecated.The caller will block until all the hbase:meta log files of the given region server have been processed - successfully split or an error is encountered - by an available worker region server.
- splitLogDistributed(Path) - Method in class org.apache.hadoop.hbase.master.SplitLogManager
-
Deprecated.
- splitLogFile(Path, FileStatus, FileSystem, Configuration, CancelableProgressable, LastSequenceId, SplitLogWorkerCoordination, WALFactory, RegionServerServices) - Static method in class org.apache.hadoop.hbase.wal.WALSplitter
-
Splits a WAL file.
- org.apache.hadoop.hbase.master.SplitLogManager - Class in org.apache.hadoop.hbase.master
-
Deprecated.since 2.4.0 and in 3.0.0, to be removed in 4.0.0, replaced by procedure-based distributed WAL splitter, see SplitWALManager.
- SplitLogManager(MasterServices, Configuration) - Constructor for class org.apache.hadoop.hbase.master.SplitLogManager
-
Deprecated.Its OK to construct this object even when region-servers are not online.
- org.apache.hadoop.hbase.master.SplitLogManager.ResubmitDirective - Enum Class in org.apache.hadoop.hbase.master
-
Deprecated.
- org.apache.hadoop.hbase.master.SplitLogManager.Task - Class in org.apache.hadoop.hbase.master
-
Deprecated.in memory state of an active task.
- org.apache.hadoop.hbase.master.SplitLogManager.TaskBatch - Class in org.apache.hadoop.hbase.master
-
Deprecated.Keeps track of the batch of tasks submitted together by a caller in splitLogDistributed().
- org.apache.hadoop.hbase.master.SplitLogManager.TerminationStatus - Enum Class in org.apache.hadoop.hbase.master
-
Deprecated.
- splitLogManagerCoordination - Variable in class org.apache.hadoop.hbase.coordination.ZkCoordinatedStateManager
-
Deprecated.
- org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination - Interface in org.apache.hadoop.hbase.coordination
-
Deprecated.since 2.4.0 and in 3.0.0, to be removed in 4.0.0, replaced by procedure-based distributed WAL splitter, see SplitWALManager
- org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination.SplitLogManagerDetails - Class in org.apache.hadoop.hbase.coordination
-
Deprecated.Detail class that shares data between coordination and split log manager
- SplitLogManagerDetails(ConcurrentMap<String, SplitLogManager.Task>, MasterServices, Set<String>) - Constructor for class org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination.SplitLogManagerDetails
-
Deprecated.
- org.apache.hadoop.hbase.SplitLogTask - Class in org.apache.hadoop.hbase
-
Deprecated.since 2.4.0 and in 3.0.0, to be removed in 4.0.0, replaced by procedure-based distributed WAL splitter, see SplitWALManager
- org.apache.hadoop.hbase.SplitLogTask.Done - Class in org.apache.hadoop.hbase
-
Deprecated.
- org.apache.hadoop.hbase.SplitLogTask.Err - Class in org.apache.hadoop.hbase
-
Deprecated.
- org.apache.hadoop.hbase.SplitLogTask.Owned - Class in org.apache.hadoop.hbase
-
Deprecated.
- org.apache.hadoop.hbase.SplitLogTask.Resigned - Class in org.apache.hadoop.hbase
-
Deprecated.
- org.apache.hadoop.hbase.SplitLogTask.Unassigned - Class in org.apache.hadoop.hbase
-
Deprecated.
- org.apache.hadoop.hbase.regionserver.SplitLogWorker - Class in org.apache.hadoop.hbase.regionserver
-
Deprecated.since 2.4.0 and in 3.0.0, to be removed in 4.0.0, replaced by procedure-based distributed WAL splitter, see SplitWALRemoteProcedure
- SplitLogWorker(Configuration, RegionServerServices, LastSequenceId, WALFactory) - Constructor for class org.apache.hadoop.hbase.regionserver.SplitLogWorker
-
Deprecated.
- SplitLogWorker(Server, Configuration, RegionServerServices, SplitLogWorker.TaskExecutor) - Constructor for class org.apache.hadoop.hbase.regionserver.SplitLogWorker
-
Deprecated.
- org.apache.hadoop.hbase.regionserver.SplitLogWorker.TaskExecutor - Interface in org.apache.hadoop.hbase.regionserver
-
Deprecated.Objects implementing this interface actually do the task that has been acquired by a
SplitLogWorker
. - org.apache.hadoop.hbase.regionserver.SplitLogWorker.TaskExecutor.Status - Enum Class in org.apache.hadoop.hbase.regionserver
-
Deprecated.
- splitLogWorkerCoordination - Variable in class org.apache.hadoop.hbase.coordination.ZkCoordinatedStateManager
-
Deprecated.
- org.apache.hadoop.hbase.coordination.SplitLogWorkerCoordination - Interface in org.apache.hadoop.hbase.coordination
-
Deprecated.since 2.4.0 and in 3.0.0, to be removed in 4.0.0, replaced by procedure-based distributed WAL splitter, see SplitWALManager
- org.apache.hadoop.hbase.coordination.SplitLogWorkerCoordination.SplitTaskDetails - Interface in org.apache.hadoop.hbase.coordination
-
Deprecated.Interface for log-split tasks Used to carry implementation details in encapsulated way through Handlers to the coordination API.
- splitLogZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZNodePaths
- splitMetaLog(Set<ServerName>) - Method in class org.apache.hadoop.hbase.master.MasterWalManager
-
Specialized method to handle the splitting for meta WAL
- splitMetaLog(ServerName) - Method in class org.apache.hadoop.hbase.master.MasterWalManager
-
Specialized method to handle the splitting for meta WAL
- org.apache.hadoop.hbase.master.SplitOrMergeStateStore - Class in org.apache.hadoop.hbase.master
-
Tracks the switch of split and merge states.
- SplitOrMergeStateStore(MasterRegion, ZKWatcher, Configuration) - Constructor for class org.apache.hadoop.hbase.master.SplitOrMergeStateStore
- splitRegion(byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Split an individual region.
- splitRegion(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Split an individual region.
- splitRegion(RegionInfo, byte[], long, long) - Method in class org.apache.hadoop.hbase.master.HMaster
- splitRegion(RegionInfo, byte[], long, long) - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Split a region.
- splitRegion(RpcController, MasterProtos.SplitTableRegionRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- splitRegionAsync(byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Split an individual region.
- splitRegionAsync(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Split an individual region.
- splits - Variable in class org.apache.hadoop.hbase.wal.BoundedRecoveredHFilesOutputSink
-
List of all the files produced by this sink,
- splitStoreFile(RegionInfo, String, HStoreFile, byte[], boolean, RegionSplitPolicy, StoreFileTracker) - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
Write out a split reference.
- splitSwitch(boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Turn the Split switch on or off.
- splitSwitch(boolean, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Turn the split switch on or off.
- splitSwitch(boolean, boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Turn the Split switch on or off.
- SPLITTER - Static variable in class org.apache.hadoop.hbase.util.Strings
- SPLITTING - Enum constant in enum class org.apache.hadoop.hbase.master.RegionState.State
- SPLITTING_EXT - Static variable in class org.apache.hadoop.hbase.wal.AbstractFSWALProvider
-
File Extension used while splitting an WAL into regions (HBASE-2312)
- SPLITTING_NEW - Enum constant in enum class org.apache.hadoop.hbase.master.RegionState.State
- org.apache.hadoop.hbase.regionserver.SplitWALCallable - Class in org.apache.hadoop.hbase.regionserver
-
This callable is used to do the real split WAL task.
- SplitWALCallable() - Constructor for class org.apache.hadoop.hbase.regionserver.SplitWALCallable
- org.apache.hadoop.hbase.regionserver.SplitWALCallable.ErrorWALSplitException - Exception in org.apache.hadoop.hbase.regionserver
- org.apache.hadoop.hbase.regionserver.SplitWALCallable.PreemptedWALSplitException - Exception in org.apache.hadoop.hbase.regionserver
- org.apache.hadoop.hbase.regionserver.SplitWALCallable.ResignedWALSplitException - Exception in org.apache.hadoop.hbase.regionserver
- org.apache.hadoop.hbase.master.SplitWALManager - Class in org.apache.hadoop.hbase.master
-
Create
SplitWALProcedure
for each WAL which need to split. - SplitWALManager(MasterServices) - Constructor for class org.apache.hadoop.hbase.master.SplitWALManager
- splitWALs(ServerName, boolean) - Method in class org.apache.hadoop.hbase.master.SplitWALManager
- SPNEGO_FILTER - Static variable in class org.apache.hadoop.hbase.http.HttpServer
- SPNEGO_PROXYUSER_FILTER - Static variable in class org.apache.hadoop.hbase.http.HttpServer
- src - Variable in class org.apache.hadoop.hbase.types.StructIterator
- org.apache.hadoop.hbase.exceptions.SSLContextException - Exception in org.apache.hadoop.hbase.exceptions
- SSLContextException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.SSLContextException
- SSLContextException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.exceptions.SSLContextException
- SSLContextException(Throwable) - Constructor for exception org.apache.hadoop.hbase.exceptions.SSLContextException
- org.apache.hadoop.hbase.SslRMIClientSocketFactorySecure - Class in org.apache.hadoop.hbase
-
Avoid SSL V3.0 "Poodle" Vulnerability - CVE-2014-3566
- SslRMIClientSocketFactorySecure() - Constructor for class org.apache.hadoop.hbase.SslRMIClientSocketFactorySecure
- org.apache.hadoop.hbase.SslRMIServerSocketFactorySecure - Class in org.apache.hadoop.hbase
-
Avoid SSL V3.0 "Poodle" Vulnerability - CVE-2014-3566
- SslRMIServerSocketFactorySecure() - Constructor for class org.apache.hadoop.hbase.SslRMIServerSocketFactorySecure
- StackServlet() - Constructor for class org.apache.hadoop.hbase.http.HttpServer.StackServlet
- staleRefQueue - Variable in class org.apache.hadoop.hbase.util.ObjectPool
- stampSequenceIdAndPublishToRingBuffer(RegionInfo, WALKeyImpl, WALEdit, boolean, RingBuffer<RingBufferTruck>) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
- stampSet - Variable in class org.apache.hadoop.hbase.filter.DependentColumnFilter
- standardizeZKQuorumServerString(String, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKConfig
-
Standardize the ZK quorum string: make it a "server:clientport" list, separated by ','
- STANDBY - Enum constant in enum class org.apache.hadoop.hbase.replication.SyncReplicationState
- start() - Method in class org.apache.hadoop.hbase.client.example.HttpProxyExample
- start() - Method in class org.apache.hadoop.hbase.errorhandling.TimeoutExceptionInjector
-
Start a timer to fail a process if it takes longer than the expected time to complete.
- start() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.KeyPressGenerator
- start() - Method in class org.apache.hadoop.hbase.http.HttpServer
-
Start the server.
- start() - Method in class org.apache.hadoop.hbase.http.InfoServer
- start() - Method in class org.apache.hadoop.hbase.io.FileChangeWatcher
-
Tells the background thread to start.
- start() - Method in class org.apache.hadoop.hbase.ipc.DelegatingRpcScheduler
- start() - Method in class org.apache.hadoop.hbase.ipc.FifoRpcScheduler
- start() - Method in class org.apache.hadoop.hbase.ipc.MasterFifoRpcScheduler
- start() - Method in class org.apache.hadoop.hbase.ipc.NettyRpcServer
- start() - Method in class org.apache.hadoop.hbase.ipc.RpcScheduler
-
Prepares for request serving.
- start() - Method in interface org.apache.hadoop.hbase.ipc.RpcServerInterface
- start() - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
- start() - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcServer
-
Deprecated.Starts the service.
- start() - Method in class org.apache.hadoop.hbase.master.DrainingServerTracker
-
Starts the tracking of draining RegionServers.
- start() - Method in class org.apache.hadoop.hbase.master.TableNamespaceManager
- start() - Method in class org.apache.hadoop.hbase.namespace.NamespaceAuditor
- start() - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
- start() - Method in class org.apache.hadoop.hbase.quotas.QuotaCache
- start() - Method in class org.apache.hadoop.hbase.quotas.RegionServerSpaceQuotaManager
- start() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreCompactor
-
---------------------------------------------------------------------- The request to dispatch the compaction asynchronous task.
- start() - Method in class org.apache.hadoop.hbase.regionserver.SecureBulkLoadManager
- start() - Method in class org.apache.hadoop.hbase.regionserver.SplitLogWorker
-
Deprecated.start the SplitLogWorker thread
- start() - Method in class org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint
- start() - Method in interface org.apache.hadoop.hbase.replication.ReplicationEndpoint
-
Initiates service startup and returns immediately.
- start() - Method in class org.apache.hadoop.hbase.replication.VerifyWALEntriesReplicationEndpoint
- start() - Method in interface org.apache.hadoop.hbase.rsgroup.RSGroupInfoManager
- start() - Method in interface org.apache.hadoop.hbase.testing.TestingHBaseCluster
-
Start the whole mini cluster, including zookeeper cluster, dfs cluster and hbase cluster.
- start() - Method in class org.apache.hadoop.hbase.util.JvmPauseMonitor
- start() - Method in class org.apache.hadoop.hbase.util.MovingAverage
-
Mark start time of an execution.
- start() - Method in class org.apache.hadoop.hbase.zookeeper.MasterMaintenanceModeTracker
-
Starts the tracking of whether master is in Maintenance Mode.
- start() - Method in class org.apache.hadoop.hbase.zookeeper.ZKLeaderManager
-
Deprecated.
- start() - Method in class org.apache.hadoop.hbase.zookeeper.ZKNodeTracker
-
Starts the tracking of the node in ZooKeeper.
- start(int) - Method in class org.apache.hadoop.hbase.ipc.RpcExecutor
- start(long, long, int) - Method in class org.apache.hadoop.hbase.util.MultiThreadedAction
- start(long, long, int) - Method in class org.apache.hadoop.hbase.util.MultiThreadedReader
- start(long, long, int) - Method in class org.apache.hadoop.hbase.util.MultiThreadedUpdater
- start(long, long, int) - Method in class org.apache.hadoop.hbase.util.MultiThreadedWriter
- start(long, long, int) - Method in class org.apache.hadoop.hbase.util.MultiThreadedWriterBase
- start(long, long, int) - Method in class org.apache.hadoop.hbase.util.MultiThreadedWriterWithACL
- start(String) - Method in class org.apache.hadoop.hbase.regionserver.throttle.NoLimitThroughputController
- start(String) - Method in class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareThroughputController
- start(String) - Method in interface org.apache.hadoop.hbase.regionserver.throttle.ThroughputController
-
Start the throughput controller.
- start(Map<byte[], List<Cell>>) - Method in class org.apache.hadoop.hbase.regionserver.throttle.StoreHotnessProtector
- start(ChoreService) - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager
- start(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.MetaTableMetrics
- start(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.MultiRowMutationEndpoint
-
Stores a reference to the coprocessor environment provided by the
RegionCoprocessorHost
from the region where this coprocessor is loaded. - start(CoprocessorEnvironment) - Method in interface org.apache.hadoop.hbase.Coprocessor
-
Called by the
CoprocessorEnvironment
during it's own startup to initialize the coprocessor. - start(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.JMXListener
- start(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.quotas.MasterQuotasObserver
- start(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
-
Deprecated.
- start(RpcScheduler) - Method in class org.apache.hadoop.hbase.quotas.RegionServerRpcQuotaManager
- START - Static variable in class org.apache.hadoop.hbase.mapreduce.SimpleTotalOrderPartitioner
-
Deprecated.since 0.90.0
- START_CODE - Enum constant in enum class org.apache.hadoop.hbase.hbtop.field.Field
- START_KEY - Enum constant in enum class org.apache.hadoop.hbase.hbtop.field.Field
- START_KEY - Static variable in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- START_KEY_BYTES - Static variable in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- START_TIME_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.WALInputFormat
- startBlockEncoding(HFileBlockEncodingContext, DataOutputStream) - Method in class org.apache.hadoop.hbase.io.encoding.PrefixKeyDeltaEncoder
- startBlockEncoding(HFileBlockEncodingContext, DataOutputStream) - Method in class org.apache.hadoop.hbase.io.encoding.CopyKeyDataBlockEncoder
- startBlockEncoding(HFileBlockEncodingContext, DataOutputStream) - Method in interface org.apache.hadoop.hbase.io.encoding.DataBlockEncoder
-
Starts encoding for a block of KeyValues.
- startBlockEncoding(HFileBlockEncodingContext, DataOutputStream) - Method in class org.apache.hadoop.hbase.io.encoding.RowIndexCodecV1
- startBlockEncoding(HFileBlockEncodingContext, DataOutputStream) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoder
-
Starts encoding for a block of KeyValues.
- startBlockEncoding(HFileBlockEncodingContext, DataOutputStream) - Method in class org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoderImpl
- startBlockEncoding(HFileBlockEncodingContext, DataOutputStream) - Method in class org.apache.hadoop.hbase.io.hfile.NoOpDataBlockEncoder
- startBold() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.batch.BatchTerminalPrinter
- startBold() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.TerminalPrinterImpl
- startBold() - Method in interface org.apache.hadoop.hbase.hbtop.terminal.TerminalPrinter
- startCacheFlush(byte[], Map<byte[], Long>) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
- startCacheFlush(byte[], Map<byte[], Long>) - Method in interface org.apache.hadoop.hbase.wal.WAL
- startCacheFlush(byte[], Set<byte[]>) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
- startCacheFlush(byte[], Set<byte[]>) - Method in interface org.apache.hadoop.hbase.wal.WAL
-
WAL keeps track of the sequence numbers that are as yet not flushed im memstores in order to be able to do accounting to figure which WALs can be let go.
- startCancel() - Method in class org.apache.hadoop.hbase.client.ClientCoprocessorRpcController
- startCancel() - Method in class org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
- startCancel() - Method in class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
- startCancel() - Method in class org.apache.hadoop.hbase.ipc.ServerRpcController
- startChore() - Method in class org.apache.hadoop.hbase.master.ServerManager
-
start chore in ServerManager
- startcode - Variable in class org.apache.hadoop.hbase.HBaseServerBase
-
This servers startcode.
- STARTCODE_QUALIFIER - Static variable in class org.apache.hadoop.hbase.HConstants
-
The startcode column qualifier
- STARTCODE_QUALIFIER_STR - Static variable in class org.apache.hadoop.hbase.HConstants
-
The startcode column qualifier
- startConnectorServer(int, int) - Method in class org.apache.hadoop.hbase.JMXListener
- startDataNode(ServerName) - Method in class org.apache.hadoop.hbase.HBaseCluster
-
Deprecated.Starts a new datanode on the given hostname or if this is a mini/local cluster, silently logs warning message.
- startDataNode(ServerName) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.
- started(ServerName) - Method in class org.apache.hadoop.hbase.master.MasterRegionServerList
- started(ServerName) - Method in interface org.apache.hadoop.hbase.master.RegionServerList
-
Called when a region server join the cluster.
- startHandlers(int) - Method in class org.apache.hadoop.hbase.ipc.RpcExecutor
- startHandlers(int) - Method in class org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
- startHandlers(String, int, List<BlockingQueue<CallRunner>>, int, int, int, AtomicInteger) - Method in class org.apache.hadoop.hbase.ipc.RpcExecutor
-
Start up our handlers.
- startHBaseCluster() - Method in interface org.apache.hadoop.hbase.testing.TestingHBaseCluster
-
Start the hbase cluster.
- startHighlight() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.batch.BatchTerminalPrinter
- startHighlight() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.TerminalPrinterImpl
- startHighlight() - Method in interface org.apache.hadoop.hbase.hbtop.terminal.TerminalPrinter
- startInfoServer() - Method in class org.apache.hadoop.hbase.thrift.ThriftServer
- STARTING - Enum constant in enum class org.apache.hadoop.hbase.Coprocessor.State
- STARTING - Enum constant in enum class org.apache.hadoop.hbase.io.FileChangeWatcher.State
- startKey - Variable in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher
-
Key to seek to in memstore and StoreFiles
- startKey - Variable in class org.apache.hadoop.hbase.util.LoadTestTool
- startKey - Variable in class org.apache.hadoop.hbase.util.MultiThreadedAction
-
The start key of the key range, inclusive
- startMaster() - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.Starts a master thread running
- startMaster() - Method in interface org.apache.hadoop.hbase.testing.TestingHBaseCluster
-
Start a new master with localhost and random port.
- startMaster(String, int) - Method in class org.apache.hadoop.hbase.HBaseCluster
-
Deprecated.Starts a new master on the given hostname or if this is a mini/local cluster, starts a master locally.
- startMaster(String, int) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.
- startMaster(String, int) - Method in interface org.apache.hadoop.hbase.testing.TestingHBaseCluster
-
Start a new master bind on the given host and port.
- startMiniCluster() - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Start up a minicluster of hbase, dfs and zookeeper all using default options.
- startMiniCluster(boolean) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.since 2.2.0 and will be removed in 4.0.0. Use
HBaseTestingUtility.startMiniCluster(StartMiniClusterOption)
instead. - startMiniCluster(int) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Start up a minicluster of hbase, dfs and zookeeper clusters with given slave node number.
- startMiniCluster(int, boolean) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.since 2.2.0 and will be removed in 4.0.0. Use
HBaseTestingUtility.startMiniCluster(StartMiniClusterOption)
instead. - startMiniCluster(int, boolean, boolean) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.since 2.2.0 and will be removed in 4.0.0. Use
HBaseTestingUtility.startMiniCluster(StartMiniClusterOption)
instead. - startMiniCluster(int, int) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.since 2.2.0 and will be removed in 4.0.0. Use
HBaseTestingUtility.startMiniCluster(StartMiniClusterOption)
instead. - startMiniCluster(int, int, boolean) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.since 2.2.0 and will be removed in 4.0.0. Use
HBaseTestingUtility.startMiniCluster(StartMiniClusterOption)
instead. - startMiniCluster(int, int, int) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.since 2.2.0 and will be removed in 4.0.0. Use
HBaseTestingUtility.startMiniCluster(StartMiniClusterOption)
instead. - startMiniCluster(int, int, int, String[], Class<? extends HMaster>, Class<? extends MiniHBaseCluster.MiniHBaseClusterRegionServer>) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.since 2.2.0 and will be removed in 4.0.0. Use
HBaseTestingUtility.startMiniCluster(StartMiniClusterOption)
instead. - startMiniCluster(int, int, int, String[], Class<? extends HMaster>, Class<? extends MiniHBaseCluster.MiniHBaseClusterRegionServer>, boolean, boolean) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.since 2.2.0 and will be removed in 4.0.0. Use
HBaseTestingUtility.startMiniCluster(StartMiniClusterOption)
instead. - startMiniCluster(int, int, String[]) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.since 2.2.0 and will be removed in 4.0.0. Use
HBaseTestingUtility.startMiniCluster(StartMiniClusterOption)
instead. - startMiniCluster(int, int, String[], boolean) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.since 2.2.0 and will be removed in 4.0.0. Use
HBaseTestingUtility.startMiniCluster(StartMiniClusterOption)
instead. - startMiniCluster(int, int, String[], Class<? extends HMaster>, Class<? extends MiniHBaseCluster.MiniHBaseClusterRegionServer>) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.since 2.2.0 and will be removed in 4.0.0. Use
HBaseTestingUtility.startMiniCluster(StartMiniClusterOption)
instead. - startMiniCluster(StartMiniClusterOption) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Start up a mini cluster of hbase, optionally dfs and zookeeper if needed.
- org.apache.hadoop.hbase.StartMiniClusterOption - Class in org.apache.hadoop.hbase
-
Deprecated.since 3.0.0, will be removed in 4.0.0. Use
TestingHBaseCluster
instead. - org.apache.hadoop.hbase.StartMiniClusterOption.Builder - Class in org.apache.hadoop.hbase
-
Deprecated.Builder pattern for creating an
StartMiniClusterOption
. - startMiniDFSCluster(int) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Start a minidfscluster.
- startMiniDFSCluster(int, String[]) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Start a minidfscluster.
- startMiniDFSCluster(int, String[], String[]) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- startMiniDFSCluster(String[]) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Start a minidfscluster.
- startMiniDFSClusterForTestWAL(int) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- startMiniHBaseCluster() - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Starts up mini hbase cluster using default options.
- startMiniHBaseCluster(int, int) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.since 2.2.0 and will be removed in 4.0.0. Use
HBaseTestingUtility.startMiniHBaseCluster(StartMiniClusterOption)
instead. - startMiniHBaseCluster(int, int, List<Integer>) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.since 2.2.0 and will be removed in 4.0.0. Use
HBaseTestingUtility.startMiniHBaseCluster(StartMiniClusterOption)
instead. - startMiniHBaseCluster(int, int, List<Integer>, Class<? extends HMaster>, Class<? extends MiniHBaseCluster.MiniHBaseClusterRegionServer>, boolean, boolean) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.since 2.2.0 and will be removed in 4.0.0. Use
HBaseTestingUtility.startMiniHBaseCluster(StartMiniClusterOption)
instead. - startMiniHBaseCluster(StartMiniClusterOption) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Starts up mini hbase cluster.
- startMiniMapReduceCluster() - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Starts a
MiniMRCluster
with a default number ofTaskTracker
's. - startMiniZKCluster() - Method in class org.apache.hadoop.hbase.HBaseZKTestingUtility
-
Deprecated.Call this if you only want a zk cluster.
- startMiniZKCluster(int, int...) - Method in class org.apache.hadoop.hbase.HBaseZKTestingUtility
-
Deprecated.Call this if you only want a zk cluster.
- startNameNode(ServerName) - Method in class org.apache.hadoop.hbase.HBaseCluster
-
Deprecated.Starts a new namenode on the given hostname or if this is a mini/local cluster, silently logs warning message.
- startNameNode(ServerName) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.
- startOperation(long, long, Stoppable) - Method in class org.apache.hadoop.hbase.regionserver.ServerNonceManager
-
Starts the operation if operation with such nonce has not already succeeded.
- startProcedureExecutor() - Method in class org.apache.hadoop.hbase.master.HMaster
- startRegionOperation() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
- startRegionOperation() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
This method needs to be called before any public call that reads or modifies data.
- startRegionOperation(Region.Operation) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
- startRegionOperation(Region.Operation) - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
This method needs to be called before any public call that reads or modifies data.
- startRegionServer() - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.Starts a region server thread running
- startRegionServer() - Method in interface org.apache.hadoop.hbase.testing.TestingHBaseCluster
-
Start a new region server with localhost and random port.
- startRegionServer(String, int) - Method in class org.apache.hadoop.hbase.HBaseCluster
-
Deprecated.Starts a new region server on the given hostname or if this is a mini/local cluster, starts a region server locally.
- startRegionServer(String, int) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.
- startRegionServer(String, int) - Method in interface org.apache.hadoop.hbase.testing.TestingHBaseCluster
-
Start a new region server bind on the given host and port.
- startRegionServerAndWait(long) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.Starts a region server thread and waits until its processed by master.
- startReplayingFromWAL() - Method in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
-
This message intends to inform the MemStore that next coming updates are going to be part of the replaying edits from WAL
- startReplayingFromWAL() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
This message intends to inform the MemStore that next coming updates are going to be part of the replaying edits from WAL
- startReplayingFromWAL() - Method in interface org.apache.hadoop.hbase.regionserver.MemStore
-
This message intends to inform the MemStore that next coming updates are going to be part of the replaying edits from WAL
- startReplicationService() - Method in interface org.apache.hadoop.hbase.regionserver.ReplicationService
-
Start replication services.
- startReplicationService() - Method in class org.apache.hadoop.hbase.replication.ReplicationSinkServiceImpl
- startRow - Variable in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.RowRange
- startRowInclusive - Variable in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.RowRange
- startsWith(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Return true if the byte array on the right is a prefix of the byte array on the left.
- startThreads(Collection<? extends Thread>) - Method in class org.apache.hadoop.hbase.util.MultiThreadedAction
- startTime - Variable in class org.apache.hadoop.hbase.ipc.ServerCall
- startTimeMs - Variable in class org.apache.hadoop.hbase.util.MultiThreadedReader.HBaseReaderThread
-
Time when the thread started
- startup() - Method in class org.apache.hadoop.hbase.coprocessor.BaseEnvironment
-
Initialize the environment
- startup() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
Start the cluster.
- startup(File) - Method in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
- startup(File, int) - Method in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
- startup(List<JVMClusterUtil.MasterThread>, List<JVMClusterUtil.RegionServerThread>) - Static method in class org.apache.hadoop.hbase.util.JVMClusterUtil
-
Start the cluster.
- startZkNode(String, int) - Method in class org.apache.hadoop.hbase.HBaseCluster
-
Deprecated.Starts a new zookeeper node on the given hostname or if this is a mini/local cluster, silently logs warning message.
- startZkNode(String, int) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.
- STAT_THREAD_PERIOD - Static variable in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
- state - Variable in enum class org.apache.hadoop.hbase.security.SaslStatus
- STATE_QUALIFIER - Static variable in class org.apache.hadoop.hbase.HConstants
- STATE_QUALIFIER_STR - Static variable in class org.apache.hadoop.hbase.HConstants
-
The state column qualifier
- STATIC_BLOOM_SIZE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- STATIC_BLOOM_SIZE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- STATIC_INDEX_SIZE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- STATIC_INDEX_SIZE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- StaticUserFilter() - Constructor for class org.apache.hadoop.hbase.http.lib.StaticUserWebFilter.StaticUserFilter
- org.apache.hadoop.hbase.http.lib.StaticUserWebFilter - Class in org.apache.hadoop.hbase.http.lib
-
Provides a servlet filter that pretends to authenticate a fake user (Dr.Who) so that the web UI is usable for a secure cluster without authentication.
- StaticUserWebFilter() - Constructor for class org.apache.hadoop.hbase.http.lib.StaticUserWebFilter
- org.apache.hadoop.hbase.http.lib.StaticUserWebFilter.StaticUserFilter - Class in org.apache.hadoop.hbase.http.lib
- org.apache.hadoop.hbase.client.StatisticTrackable - Interface in org.apache.hadoop.hbase.client
-
Parent interface for an object to get updates about per-region statistics.
- STATS_RECORD_SEP - Static variable in class org.apache.hadoop.hbase.util.BloomFilterUtil
-
Record separator for the Bloom filter statistics human-readable string
- status - Variable in class org.apache.hadoop.hbase.master.SplitLogManager.Task
-
Deprecated.
- status - Variable in class org.apache.hadoop.hbase.wal.BoundedRecoveredHFilesOutputSink
- STATUS - Enum constant in enum class org.apache.hadoop.hbase.backup.BackupRestoreConstants.BackupCommand
- STATUS_MULTICAST_ADDRESS - Static variable in class org.apache.hadoop.hbase.HConstants
-
IP to use for the multicast status messages between the master and the clients.
- STATUS_MULTICAST_BIND_ADDRESS - Static variable in class org.apache.hadoop.hbase.HConstants
-
The address to use for binding the local socket for receiving multicast.
- STATUS_MULTICAST_NI_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
-
The network interface name to use for the multicast messages.
- STATUS_MULTICAST_PORT - Static variable in class org.apache.hadoop.hbase.HConstants
-
The port to use for the multicast messages.
- STATUS_MULTICAST_PUBLISHER_BIND_ADDRESS - Static variable in class org.apache.hadoop.hbase.HConstants
-
The address to use for binding the local socket for sending multicast.
- STATUS_PUBLISH_PERIOD - Static variable in class org.apache.hadoop.hbase.master.ClusterStatusPublisher
-
The minimum time between two status messages, in milliseconds.
- STATUS_PUBLISHED - Static variable in class org.apache.hadoop.hbase.HConstants
-
Setting to activate, or not, the publication of the status by the master.
- STATUS_PUBLISHED_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
- STATUS_PUBLISHER_CLASS - Static variable in class org.apache.hadoop.hbase.master.ClusterStatusPublisher
-
The implementation class used to publish the status.
- org.apache.hadoop.hbase.util.StealJobQueue<T> - Class in org.apache.hadoop.hbase.util
-
This queue allows a ThreadPoolExecutor to steal jobs from another ThreadPoolExecutor.
- StealJobQueue(int, int, Comparator<? super T>) - Constructor for class org.apache.hadoop.hbase.util.StealJobQueue
- StealJobQueue(Comparator<? super T>) - Constructor for class org.apache.hadoop.hbase.util.StealJobQueue
- stepDownAsLeader() - Method in class org.apache.hadoop.hbase.zookeeper.ZKLeaderManager
-
Deprecated.Removes the leader znode, if it is currently claimed by this instance.
- org.apache.hadoop.hbase.regionserver.SteppingSplitPolicy - Class in org.apache.hadoop.hbase.regionserver
- SteppingSplitPolicy() - Constructor for class org.apache.hadoop.hbase.regionserver.SteppingSplitPolicy
- stop() - Method in class org.apache.hadoop.hbase.client.example.HttpProxyExample
- stop() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.KeyPressGenerator
- stop() - Method in class org.apache.hadoop.hbase.http.HttpServer
-
stop the server
- stop() - Method in class org.apache.hadoop.hbase.http.InfoServer
- stop() - Method in class org.apache.hadoop.hbase.io.FileChangeWatcher
-
Tells the background thread to stop.
- stop() - Method in class org.apache.hadoop.hbase.ipc.DelegatingRpcScheduler
- stop() - Method in class org.apache.hadoop.hbase.ipc.FifoRpcScheduler
- stop() - Method in class org.apache.hadoop.hbase.ipc.MasterFifoRpcScheduler
- stop() - Method in class org.apache.hadoop.hbase.ipc.NettyRpcServer
- stop() - Method in class org.apache.hadoop.hbase.ipc.RpcExecutor
- stop() - Method in class org.apache.hadoop.hbase.ipc.RpcScheduler
-
Stops serving new requests.
- stop() - Method in interface org.apache.hadoop.hbase.ipc.RpcServerInterface
- stop() - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
- stop() - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcServer
-
Deprecated.Stops the service.
- stop() - Method in class org.apache.hadoop.hbase.master.ActiveMasterManager
- stop() - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
- stop() - Method in class org.apache.hadoop.hbase.master.MasterWalManager
- stop() - Method in class org.apache.hadoop.hbase.master.RegionServerTracker
- stop() - Method in class org.apache.hadoop.hbase.master.ServerManager
-
Stop the ServerManager.
- stop() - Method in class org.apache.hadoop.hbase.master.SplitLogManager
-
Deprecated.
- stop() - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
- stop() - Method in class org.apache.hadoop.hbase.quotas.RegionServerRpcQuotaManager
- stop() - Method in class org.apache.hadoop.hbase.quotas.RegionServerSpaceQuotaManager
- stop() - Method in class org.apache.hadoop.hbase.regionserver.BootstrapNodeManager
- stop() - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager
- stop() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreCompactor
-
---------------------------------------------------------------------- The request to cancel the compaction asynchronous task The compaction may still happen if the request was sent too late Non-blocking request
- stop() - Method in class org.apache.hadoop.hbase.regionserver.regionreplication.RegionReplicationBufferManager
- stop() - Method in class org.apache.hadoop.hbase.regionserver.regionreplication.RegionReplicationSink
-
Stop the replication sink.
- stop() - Method in class org.apache.hadoop.hbase.regionserver.SecureBulkLoadManager
- stop() - Method in class org.apache.hadoop.hbase.regionserver.SplitLogWorker
-
Deprecated.stop the SplitLogWorker thread
- stop() - Method in class org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint
- stop() - Method in interface org.apache.hadoop.hbase.replication.ReplicationEndpoint
-
If the service is starting or running, this initiates service shutdown and returns immediately.
- stop() - Method in class org.apache.hadoop.hbase.replication.VerifyWALEntriesReplicationEndpoint
- stop() - Method in class org.apache.hadoop.hbase.rest.RESTServer
- stop() - Static method in class org.apache.hadoop.hbase.rest.RESTServlet
- stop() - Method in interface org.apache.hadoop.hbase.testing.TestingHBaseCluster
-
Stop the whole mini cluster, including zookeeper cluster, dfs cluster and hbase cluster.
- stop() - Method in class org.apache.hadoop.hbase.thrift.TBoundedThreadPoolServer
- stop() - Method in class org.apache.hadoop.hbase.thrift.ThriftServer
- stop() - Method in class org.apache.hadoop.hbase.util.JvmPauseMonitor
- stop() - Method in class org.apache.hadoop.hbase.zookeeper.ZKNodeTracker
- stop() - Method in interface org.apache.hadoop.metrics2.MetricsExecutor
- stop(long) - Method in class org.apache.hadoop.hbase.util.MovingAverage
-
Mark end time of an execution, and return its interval.
- stop(String) - Method in class org.apache.hadoop.hbase.backup.BackupHFileCleaner
- stop(String) - Method in class org.apache.hadoop.hbase.master.HMaster
- stop(String) - Method in class org.apache.hadoop.hbase.MockRegionServerServices
- stop(String) - Method in class org.apache.hadoop.hbase.quotas.QuotaCache
- stop(String) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
- stop(String) - Method in class org.apache.hadoop.hbase.regionserver.throttle.NoLimitThroughputController
- stop(String) - Method in class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareThroughputController
- stop(String) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupBasedLoadBalancer
- stop(String) - Method in interface org.apache.hadoop.hbase.Stoppable
-
Stop this service.
- stop(String, boolean, User) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Stops the regionserver.
- stop(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.MetaTableMetrics
- stop(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.MultiRowMutationEndpoint
- stop(CoprocessorEnvironment) - Method in interface org.apache.hadoop.hbase.Coprocessor
-
Called by the
CoprocessorEnvironment
during it's own shutdown to stop the coprocessor. - stop(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.JMXListener
- STOP - Enum constant in enum class org.apache.hadoop.hbase.backup.BackupRestoreConstants.BackupCommand
- STOP_TIMEOUT_CONF_KEY - Static variable in class org.apache.hadoop.hbase.thrift.HThreadedSelectorServerArgs
-
Time to wait for server to stop gracefully
- stopBold() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.batch.BatchTerminalPrinter
- stopBold() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.TerminalPrinterImpl
- stopBold() - Method in interface org.apache.hadoop.hbase.hbtop.terminal.TerminalPrinter
- stopChores() - Method in class org.apache.hadoop.hbase.HBaseServerBase
- stopChores() - Method in class org.apache.hadoop.hbase.master.HMaster
- stopChores() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
- stopChoreService() - Method in class org.apache.hadoop.hbase.HBaseServerBase
- stopConnectorServer() - Method in class org.apache.hadoop.hbase.JMXListener
- stopDataNode(ServerName) - Method in class org.apache.hadoop.hbase.HBaseCluster
-
Deprecated.Stops the datanode if this is a distributed cluster, otherwise silently logs warning message.
- stopDataNode(ServerName) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.
- stopExecutorService() - Method in class org.apache.hadoop.hbase.HBaseServerBase
- stopHBaseCluster() - Method in interface org.apache.hadoop.hbase.testing.TestingHBaseCluster
-
Stop the hbase cluster.
- stopHighlight() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.batch.BatchTerminalPrinter
- stopHighlight() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.TerminalPrinterImpl
- stopHighlight() - Method in interface org.apache.hadoop.hbase.hbtop.terminal.TerminalPrinter
- stopInfoServer() - Method in class org.apache.hadoop.hbase.HBaseServerBase
- stopMaster() - Method in interface org.apache.hadoop.hbase.client.Admin
-
Shuts down the current HBase master only.
- stopMaster() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Shuts down the current HBase master only.
- stopMaster() - Method in class org.apache.hadoop.hbase.master.HMaster
- stopMaster(int) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.Shut down the specified master cleanly
- stopMaster(int, boolean) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.Shut down the specified master cleanly
- stopMaster(ServerName) - Method in class org.apache.hadoop.hbase.HBaseCluster
-
Deprecated.Stops the given master, by attempting a gradual stop.
- stopMaster(ServerName) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.
- stopMaster(ServerName) - Method in interface org.apache.hadoop.hbase.testing.TestingHBaseCluster
-
Stop the given master.
- stopMaster(RpcController, MasterProtos.StopMasterRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- stopNameNode(ServerName) - Method in class org.apache.hadoop.hbase.HBaseCluster
-
Deprecated.Stops the namenode if this is a distributed cluster, otherwise silently logs warning message.
- stopNameNode(ServerName) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.
- org.apache.hadoop.hbase.Stoppable - Interface in org.apache.hadoop.hbase
-
Implementers are Stoppable.
- stopped - Variable in class org.apache.hadoop.hbase.HBaseServerBase
- STOPPED - Enum constant in enum class org.apache.hadoop.hbase.Coprocessor.State
- STOPPED - Enum constant in enum class org.apache.hadoop.hbase.io.FileChangeWatcher.State
- org.apache.hadoop.hbase.ipc.StoppedRpcClientException - Exception in org.apache.hadoop.hbase.ipc
- StoppedRpcClientException() - Constructor for exception org.apache.hadoop.hbase.ipc.StoppedRpcClientException
- StoppedRpcClientException(String) - Constructor for exception org.apache.hadoop.hbase.ipc.StoppedRpcClientException
- STOPPING - Enum constant in enum class org.apache.hadoop.hbase.Coprocessor.State
- STOPPING - Enum constant in enum class org.apache.hadoop.hbase.io.FileChangeWatcher.State
- stopProcessingTasks() - Method in interface org.apache.hadoop.hbase.coordination.SplitLogWorkerCoordination
-
Deprecated.called when Coordination should stop processing tasks and exit
- stopProcessingTasks() - Method in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination
- stopRegionServer(int) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.Shut down the specified region server cleanly
- stopRegionServer(int, boolean) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.Shut down the specified region server cleanly
- stopRegionServer(String) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Stop the designated regionserver.
- stopRegionServer(ServerName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Stop the designated regionserver.
- stopRegionServer(ServerName) - Method in class org.apache.hadoop.hbase.HBaseCluster
-
Deprecated.Stops the given region server, by attempting a gradual stop.
- stopRegionServer(ServerName) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.
- stopRegionServer(ServerName) - Method in interface org.apache.hadoop.hbase.testing.TestingHBaseCluster
-
Stop the given region server.
- stopReplayingFromWAL() - Method in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
-
This message intends to inform the MemStore that the replaying edits from WAL are done
- stopReplayingFromWAL() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
This message intends to inform the MemStore that the replaying edits from WAL are done
- stopReplayingFromWAL() - Method in interface org.apache.hadoop.hbase.regionserver.MemStore
-
This message intends to inform the MemStore that the replaying edits from WAL are done
- stopReplicationService() - Method in interface org.apache.hadoop.hbase.regionserver.ReplicationService
-
Stops replication service.
- stopReplicationService() - Method in class org.apache.hadoop.hbase.replication.ReplicationSinkServiceImpl
- stopRow - Variable in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.RowRange
- stopRow - Variable in class org.apache.hadoop.hbase.regionserver.querymatcher.UserScanQueryMatcher
- stopRowInclusive - Variable in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.RowRange
- stopRunning() - Method in class org.apache.hadoop.hbase.ipc.RpcHandler
- stopServer(AdminProtos.StopServerRequest) - Method in class org.apache.hadoop.hbase.client.AsyncRegionServerAdmin
- stopServer(RpcController, AdminProtos.StopServerRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- stopServer(RpcController, AdminProtos.StopServerRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
Stop the region server.
- stopServiceThreads() - Method in class org.apache.hadoop.hbase.master.HMaster
- stopServiceThreads() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Wait on all threads to finish.
- stopTask() - Method in class org.apache.hadoop.hbase.regionserver.SplitLogWorker
-
Deprecated.If the worker is doing a task i.e.
- stopZkNode(ServerName) - Method in class org.apache.hadoop.hbase.HBaseCluster
-
Deprecated.Stops the region zookeeper if this is a distributed cluster, otherwise silently logs warning message.
- stopZkNode(ServerName) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.
- STORAGE_POLICY - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
- STORAGE_POLICY_PREFIX - Static variable in class org.apache.hadoop.hbase.HConstants
-
Date Tiered Compaction tmp dir prefix name if use storage policy
- STORAGE_POLICY_PROPERTY - Static variable in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
- STORAGE_POLICY_PROPERTY_CF_PREFIX - Static variable in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
- org.apache.hadoop.hbase.rest.StorageClusterStatusResource - Class in org.apache.hadoop.hbase.rest
- StorageClusterStatusResource() - Constructor for class org.apache.hadoop.hbase.rest.StorageClusterStatusResource
-
Constructor
- org.apache.hadoop.hbase.rest.StorageClusterVersionResource - Class in org.apache.hadoop.hbase.rest
- StorageClusterVersionResource() - Constructor for class org.apache.hadoop.hbase.rest.StorageClusterVersionResource
-
Constructor
- store - Variable in class org.apache.hadoop.hbase.io.crypto.KeyStoreKeyProvider
- store - Variable in class org.apache.hadoop.hbase.regionserver.DefaultStoreFlusher
- store - Variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
- org.apache.hadoop.hbase.regionserver.Store - Interface in org.apache.hadoop.hbase.regionserver
-
Interface for objects that hold a column family in a Region.
- STORE_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- STORE_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- STORE_ENGINE_CLASS_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.StoreEngine
-
The name of the configuration parameter that specifies the class of a store engine that is used to manage and compact HBase store files.
- STORE_FILE_READER_NO_READAHEAD - Static variable in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
- STORE_FILE_REF_COUNT_THRESHOLD - Static variable in class org.apache.hadoop.hbase.HConstants
- STORE_FILE_SIZE - Enum constant in enum class org.apache.hadoop.hbase.hbtop.field.Field
- STORE_MANIFEST - Enum constant in enum class org.apache.hadoop.hbase.backup.BackupInfo.BackupPhase
- STORE_REF_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- STORE_REF_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- STORE_SERVICES - Static variable in class org.apache.hadoop.hbase.util.ClassSize
- STORE_TOO_BUSY - Enum constant in enum class org.apache.hadoop.hbase.HConstants.OperationStatusCode
- org.apache.hadoop.hbase.regionserver.StoreConfigInformation - Interface in org.apache.hadoop.hbase.regionserver
-
A more restricted interface for HStore.
- org.apache.hadoop.hbase.regionserver.StoreContext - Class in org.apache.hadoop.hbase.regionserver
-
This carries the immutable information and references on some of the meta data about the HStore.
- org.apache.hadoop.hbase.regionserver.StoreContext.Builder - Class in org.apache.hadoop.hbase.regionserver
- org.apache.hadoop.hbase.regionserver.StoreEngine<SF extends org.apache.hadoop.hbase.regionserver.StoreFlusher,
CP extends org.apache.hadoop.hbase.regionserver.compactions.CompactionPolicy, C extends org.apache.hadoop.hbase.regionserver.compactions.Compactor<?>, SFM extends org.apache.hadoop.hbase.regionserver.StoreFileManager> - Class in org.apache.hadoop.hbase.regionserver -
StoreEngine is a factory that can create the objects necessary for HStore to operate.
- StoreEngine() - Constructor for class org.apache.hadoop.hbase.regionserver.StoreEngine
- storeFile(String, String, String) - Method in interface org.apache.hadoop.hbase.util.FSVisitor.StoreFileVisitor
- storeFile(RegionInfo, String, SnapshotProtos.SnapshotRegionManifest.StoreFile) - Method in interface org.apache.hadoop.hbase.snapshot.SnapshotReferenceUtil.StoreFileVisitor
- org.apache.hadoop.hbase.regionserver.StoreFile - Interface in org.apache.hadoop.hbase.regionserver
-
An interface to describe a store data file.
- STOREFILE_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- STOREFILE_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- STOREFILE_INDEX_SIZE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- STOREFILE_INDEX_SIZE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- STOREFILE_SIZE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- STOREFILE_SIZE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- STOREFILE_SIZE_GROWTH_RATE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- STOREFILE_SIZE_GROWTH_RATE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- org.apache.hadoop.hbase.regionserver.StoreFileInfo - Class in org.apache.hadoop.hbase.regionserver
-
Describe a StoreFile (hfile, reference, link)
- StoreFileInfo(Configuration, FileSystem, long, Path, long, Reference, HFileLink, boolean) - Constructor for class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
Create a Store File Info from an HFileLink and a Reference
- StoreFileInfo(Configuration, FileSystem, FileStatus, HFileLink) - Constructor for class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
Create a Store File Info from an HFileLink
- StoreFileInfo(Configuration, FileSystem, FileStatus, Reference) - Constructor for class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
Create a Store File Info from an HFileLink
- StoreFileInfo(Configuration, FileSystem, FileStatus, Reference, HFileLink) - Constructor for class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
Create a Store File Info from an HFileLink and a Reference
- org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileListFilePrettyPrinter - Class in org.apache.hadoop.hbase.regionserver.storefiletracker
- StoreFileListFilePrettyPrinter() - Constructor for class org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileListFilePrettyPrinter
- StoreFileListFilePrettyPrinter(Configuration) - Constructor for class org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileListFilePrettyPrinter
- storeFileManager - Variable in class org.apache.hadoop.hbase.regionserver.StoreEngine
- org.apache.hadoop.hbase.regionserver.StoreFileManager - Interface in org.apache.hadoop.hbase.regionserver
-
Manages the store files and basic metadata about that that determines the logical structure (e.g.
- org.apache.hadoop.hbase.regionserver.StoreFileReader - Class in org.apache.hadoop.hbase.regionserver
-
Reader for a StoreFile.
- StoreFileReader(ReaderContext, HFileInfo, CacheConfig, StoreFileInfo, Configuration) - Constructor for class org.apache.hadoop.hbase.regionserver.StoreFileReader
- org.apache.hadoop.hbase.regionserver.StorefileRefresherChore - Class in org.apache.hadoop.hbase.regionserver
-
A chore for refreshing the store files for secondary regions hosted in the region server.
- StorefileRefresherChore(int, boolean, HRegionServer, Stoppable) - Constructor for class org.apache.hadoop.hbase.regionserver.StorefileRefresherChore
- org.apache.hadoop.hbase.regionserver.StoreFileScanner - Class in org.apache.hadoop.hbase.regionserver
-
KeyValueScanner adaptor over the Reader.
- StoreFileScanner(StoreFileReader, HFileScanner, boolean, boolean, long, long, boolean, boolean) - Constructor for class org.apache.hadoop.hbase.regionserver.StoreFileScanner
-
Implements a
KeyValueScanner
on top of the specifiedHFileScanner
- org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileTracker - Interface in org.apache.hadoop.hbase.regionserver.storefiletracker
-
An interface to define how we track the store files for a give store.
- org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileTrackerFactory - Class in org.apache.hadoop.hbase.regionserver.storefiletracker
-
Factory method for creating store file tracker.
- org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileTrackerFactory.Trackers - Enum Class in org.apache.hadoop.hbase.regionserver.storefiletracker
-
Maps between configuration names for trackers and implementation classes.
- org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileTrackerValidationUtils - Class in org.apache.hadoop.hbase.regionserver.storefiletracker
- org.apache.hadoop.hbase.regionserver.StoreFileWriter - Class in org.apache.hadoop.hbase.regionserver
-
A StoreFile writer.
- org.apache.hadoop.hbase.regionserver.StoreFileWriter.Builder - Class in org.apache.hadoop.hbase.regionserver
- storeFlusher - Variable in class org.apache.hadoop.hbase.regionserver.StoreEngine
- org.apache.hadoop.hbase.regionserver.throttle.StoreHotnessProtector - Class in org.apache.hadoop.hbase.regionserver.throttle
-
StoreHotnessProtector is designed to help limit the concurrency of puts with dense columns, it does best-effort to avoid exhausting all RS's handlers.
- StoreHotnessProtector(Region, Configuration) - Constructor for class org.apache.hadoop.hbase.regionserver.throttle.StoreHotnessProtector
- stores - Variable in class org.apache.hadoop.hbase.regionserver.HRegion
- org.apache.hadoop.hbase.regionserver.StoreScanner - Class in org.apache.hadoop.hbase.regionserver
-
Scanner scans both the memstore and the Store.
- StoreScanner(HStore, ScanInfo, List<? extends KeyValueScanner>, long, long, byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.regionserver.StoreScanner
-
Used for compactions that drop deletes from a limited range of rows.
- StoreScanner(HStore, ScanInfo, List<? extends KeyValueScanner>, ScanType, long, long) - Constructor for class org.apache.hadoop.hbase.regionserver.StoreScanner
-
Used for store file compaction and memstore compaction.
- StoreScanner(HStore, ScanInfo, Scan, NavigableSet<byte[]>, long) - Constructor for class org.apache.hadoop.hbase.regionserver.StoreScanner
-
Opens a scanner across memstore, snapshot, and all StoreFiles.
- StoreScanner(ScanInfo, ScanType, List<? extends KeyValueScanner>) - Constructor for class org.apache.hadoop.hbase.regionserver.StoreScanner
- STORESCANNER_PARALLEL_SEEK_ENABLE - Static variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
- STORESCANNER_PREAD_MAX_BYTES - Static variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
If the read type is Scan.ReadType.DEFAULT, we will start with pread, and if the kvs we scanned reaches this limit, we will reopen the scanner with stream.
- storesToCompact - Variable in class org.apache.hadoop.hbase.util.compaction.MajorCompactor
- org.apache.hadoop.hbase.regionserver.StoreUtils - Class in org.apache.hadoop.hbase.regionserver
-
Utility functions for region server storage layer.
- STREAM - Enum constant in enum class org.apache.hadoop.hbase.client.Scan.ReadType
- STREAM - Enum constant in enum class org.apache.hadoop.hbase.io.hfile.ReaderContext.ReaderType
- StreamLacksCapabilityException(String) - Constructor for exception org.apache.hadoop.hbase.util.CommonFSUtils.StreamLacksCapabilityException
- StreamLacksCapabilityException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.util.CommonFSUtils.StreamLacksCapabilityException
- org.apache.hadoop.hbase.io.asyncfs.monitor.StreamSlowMonitor - Class in org.apache.hadoop.hbase.io.asyncfs.monitor
-
Class for monitor the wal file flush performance.
- StreamSlowMonitor(Configuration, String, ExcludeDatanodeManager) - Constructor for class org.apache.hadoop.hbase.io.asyncfs.monitor.StreamSlowMonitor
- org.apache.hadoop.hbase.io.util.StreamUtils - Class in org.apache.hadoop.hbase.io.util
- StreamUtils() - Constructor for class org.apache.hadoop.hbase.io.util.StreamUtils
- STRING - Enum constant in enum class org.apache.hadoop.hbase.hbtop.field.FieldValueType
- STRING - Static variable in class org.apache.hadoop.hbase.util.ClassSize
-
String overhead
- STRING_VIS_TAG_TYPE - Static variable in class org.apache.hadoop.hbase.TagType
- stringFromMillis(long) - Static method in exception org.apache.hadoop.hbase.quotas.RpcThrottlingException
- stringify(Class<?>[]) - Static method in class org.apache.hadoop.hbase.util.Classes
- org.apache.hadoop.hbase.util.Strings - Class in org.apache.hadoop.hbase.util
-
Utility for Strings.
- STRIPE_END_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
- STRIPE_START_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
-
The file metadata fields that contain the stripe information.
- org.apache.hadoop.hbase.regionserver.querymatcher.StripeCompactionScanQueryMatcher - Class in org.apache.hadoop.hbase.regionserver.querymatcher
-
Query matcher for stripe compaction if range drop deletes is used.
- StripeCompactionScanQueryMatcher(ScanInfo, DeleteTracker, ColumnTracker, long, long, long, long, byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.regionserver.querymatcher.StripeCompactionScanQueryMatcher
- StripeFlushRequest(CellComparator) - Constructor for class org.apache.hadoop.hbase.regionserver.StripeStoreFlusher.StripeFlushRequest
- org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter - Class in org.apache.hadoop.hbase.regionserver
-
Base class for cell sink that separates the provided cells into multiple files for stripe compaction.
- StripeMultiFileWriter(CellComparator) - Constructor for class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter
- org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter.BoundaryMultiWriter - Class in org.apache.hadoop.hbase.regionserver
-
MultiWriter that separates the cells based on fixed row-key boundaries.
- org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter.SizeMultiWriter - Class in org.apache.hadoop.hbase.regionserver
-
MultiWriter that separates the cells based on target cell number per file and file count.
- org.apache.hadoop.hbase.regionserver.StripeStoreConfig - Class in org.apache.hadoop.hbase.regionserver
-
Configuration class for stripe store and compactions.
- StripeStoreConfig(Configuration, StoreConfigInformation) - Constructor for class org.apache.hadoop.hbase.regionserver.StripeStoreConfig
- org.apache.hadoop.hbase.regionserver.StripeStoreEngine - Class in org.apache.hadoop.hbase.regionserver
-
The storage engine that implements the stripe-based store/compaction scheme.
- StripeStoreEngine() - Constructor for class org.apache.hadoop.hbase.regionserver.StripeStoreEngine
- org.apache.hadoop.hbase.regionserver.StripeStoreFileManager - Class in org.apache.hadoop.hbase.regionserver
-
Stripe implementation of
StoreFileManager
. - StripeStoreFileManager(CellComparator, Configuration, StripeStoreConfig) - Constructor for class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
- org.apache.hadoop.hbase.regionserver.StripeStoreFlusher - Class in org.apache.hadoop.hbase.regionserver
-
Stripe implementation of StoreFlusher.
- StripeStoreFlusher(Configuration, HStore, StripeCompactionPolicy, StripeStoreFileManager) - Constructor for class org.apache.hadoop.hbase.regionserver.StripeStoreFlusher
- org.apache.hadoop.hbase.regionserver.StripeStoreFlusher.BoundaryStripeFlushRequest - Class in org.apache.hadoop.hbase.regionserver
-
Stripe flush request wrapper based on boundaries.
- org.apache.hadoop.hbase.regionserver.StripeStoreFlusher.SizeStripeFlushRequest - Class in org.apache.hadoop.hbase.regionserver
-
Stripe flush request wrapper based on size.
- org.apache.hadoop.hbase.regionserver.StripeStoreFlusher.StripeFlushRequest - Class in org.apache.hadoop.hbase.regionserver
-
Stripe flush request wrapper that writes a non-striped file.
- STRONG - Enum constant in enum class org.apache.hadoop.hbase.client.Consistency
-
Strong consistency is the default consistency model in HBase, where reads and writes go through a single server which serializes the updates, and returns all data that was written and ack'd.
- strToRow(String) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.NumberStringSplit
- strToRow(String) - Method in interface org.apache.hadoop.hbase.util.RegionSplitter.SplitAlgorithm
-
user or file input for row
- strToRow(String) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.UniformSplit
- org.apache.hadoop.hbase.types.Struct - Class in org.apache.hadoop.hbase.types
-
Struct
is a simpleDataType
for implementing "compound rowkey" and "compound qualifier" schema design strategies. - Struct(DataType[]) - Constructor for class org.apache.hadoop.hbase.types.Struct
-
Create a new
Struct
instance defined as the sequence ofHDataType
s inmemberTypes
. - org.apache.hadoop.hbase.types.StructBuilder - Class in org.apache.hadoop.hbase.types
-
A helper for building
Struct
instances. - StructBuilder() - Constructor for class org.apache.hadoop.hbase.types.StructBuilder
-
Create an empty
StructBuilder
. - org.apache.hadoop.hbase.types.StructIterator - Class in org.apache.hadoop.hbase.types
-
An
Iterator
over encodedStruct
members. - StructIterator(PositionedByteRange, DataType[]) - Constructor for class org.apache.hadoop.hbase.types.StructIterator
-
Construct
StructIterator
over the values encoded insrc
using the specifiedtypes
definition. - subFiltersIncludedCell - Variable in class org.apache.hadoop.hbase.filter.FilterListBase
-
For each sub-filter in filter list, we save a boolean flag to indicate that whether the return code of filterCell(c) for sub-filter is INCLUDE* (INCLUDE, INCLUDE_AND_NEXT_COL, INCLUDE_AND_SEEK_NEXT_ROW) case.
- subList(int, int) - Method in class org.apache.hadoop.hbase.util.SortedList
- subMap(byte[], byte[]) - Method in class org.apache.hadoop.hbase.io.hfile.HFileInfo
- subMap(K, boolean, K, boolean) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
- subMap(K, K) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
- subMap(T, boolean, T, boolean) - Method in class org.apache.hadoop.hbase.regionserver.CellFlatMap
- subMap(T, T) - Method in class org.apache.hadoop.hbase.regionserver.CellFlatMap
- submit(Callable<V>) - Method in class org.apache.hadoop.hbase.util.BoundedCompletionService
- submitTask(String) - Method in interface org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination
-
Deprecated.
- submitTask(String) - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
- subset(Configuration, String) - Static method in class org.apache.hadoop.hbase.HBaseConfiguration
-
Returns a subset of the configuration properties, matching the given key prefix.
- subSet(Cell, boolean, Cell, boolean) - Method in class org.apache.hadoop.hbase.regionserver.CellSet
- subSet(T, T) - Method in class org.apache.hadoop.hbase.regionserver.CellSet
- org.apache.hadoop.hbase.filter.SubstringComparator - Class in org.apache.hadoop.hbase.filter
-
This comparator is for use with SingleColumnValueFilter, for filtering based on the value of a given column.
- SubstringComparator(String) - Constructor for class org.apache.hadoop.hbase.filter.SubstringComparator
-
Constructor
- substringType - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
SubstringType byte array
- SUBSYSTEM_KEY - Static variable in class org.apache.hadoop.hbase.util.JSONMetricUtil
- SUCCESS - Enum constant in enum class org.apache.hadoop.hbase.HConstants.OperationStatusCode
- SUCCESS - Enum constant in enum class org.apache.hadoop.hbase.master.SplitLogManager.TerminationStatus
-
Deprecated.
- SUCCESS - Enum constant in enum class org.apache.hadoop.hbase.security.SaslStatus
- SUCCESS - Static variable in class org.apache.hadoop.hbase.regionserver.OperationStatus
-
Singleton for successful operations.
- SUCCESSFUL_APPEND_KEY - Static variable in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
- SUCCESSFUL_DELETE_KEY - Static variable in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
- SUCCESSFUL_GET_KEY - Static variable in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
- SUCCESSFUL_INCREMENT_KEY - Static variable in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
- SUCCESSFUL_LOG_ROLLS - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
- SUCCESSFUL_LOG_ROLLS_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
- SUCCESSFUL_PUT_KEY - Static variable in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
- SUCCESSFUL_SCAN_KEY - Static variable in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
- sum() - Method in class org.apache.hadoop.hbase.CacheEvictionStatsAggregator
- summarize() - Method in interface org.apache.hadoop.hbase.util.HbckErrorReporter
-
Deprecated.
- org.apache.hadoop.hbase.hbtop.screen.top.Summary - Class in org.apache.hadoop.hbase.hbtop.screen.top
-
Represents the summary of the metrics.
- Summary(String, String, String, int, int, int, int, int, double, long) - Constructor for class org.apache.hadoop.hbase.hbtop.screen.top.Summary
- SUN_MGMT_DOMAIN - Static variable in class org.apache.hadoop.hbase.util.JSONMetricUtil
- SUPERUSER_CONF_KEY - Static variable in class org.apache.hadoop.hbase.security.Superusers
-
Configuration key for superusers
- org.apache.hadoop.hbase.security.Superusers - Class in org.apache.hadoop.hbase.security
-
Keeps lists of superusers and super groups loaded from HBase configuration, checks if certain user is regarded as superuser.
- org.apache.hadoop.hbase.http.jersey.SupplierFactoryAdapter<T> - Class in org.apache.hadoop.hbase.http.jersey
- SupplierFactoryAdapter(Supplier<T>) - Constructor for class org.apache.hadoop.hbase.http.jersey.SupplierFactoryAdapter
- supportSafeMode(FileSystem) - Static method in class org.apache.hadoop.hbase.util.FSUtils
- supportsAutoLoading() - Method in class org.apache.hadoop.hbase.io.hfile.CompoundBloomFilter
- supportsAutoLoading() - Method in interface org.apache.hadoop.hbase.util.BloomFilter
- suspend() - Method in interface org.apache.hadoop.hbase.client.AdvancedScanResultConsumer.ScanController
-
Suspend the scan.
- suspend(Procedure<?>) - Method in class org.apache.hadoop.hbase.master.WorkerAssigner
- suspendRegionServer(int) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.Suspend the specified region server
- suspendRegionServer(ServerName) - Method in class org.apache.hadoop.hbase.HBaseCluster
-
Deprecated.Suspend the region server
- suspendRegionServer(ServerName) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.
- swap(VersionedSegmentsList, ImmutableSegment, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.CompactionPipeline
-
Swaps the versioned list at the tail of the pipeline with a new segment.
- swapCompactedSegments(VersionedSegmentsList, ImmutableSegment, boolean) - Method in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
- swapPipelineWithNull(VersionedSegmentsList) - Method in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
- sweep() - Method in class org.apache.hadoop.hbase.util.LossyCounting
-
sweep low frequency data
- sweep(T) - Method in interface org.apache.hadoop.hbase.util.LossyCounting.LossyCountingListener
- SWITCH_TO_SIMPLE_AUTH - Static variable in class org.apache.hadoop.hbase.security.SaslUtil
- switchCompaction(boolean) - Method in class org.apache.hadoop.hbase.regionserver.CompactSplit
- switchExceedThrottleQuota(Connection, boolean) - Static method in class org.apache.hadoop.hbase.quotas.QuotaUtil
- switchExceedThrottleQuota(MasterProtos.SwitchExceedThrottleQuotaRequest) - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
- switchExceedThrottleQuota(RpcController, MasterProtos.SwitchExceedThrottleQuotaRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- switchFieldDisplay() - Method in class org.apache.hadoop.hbase.hbtop.screen.field.FieldScreenPresenter
- switchMode(Mode, boolean, List<RecordFilter>) - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenModel
- switchMode(Mode, Field, boolean, List<Field>, Boolean, List<RecordFilter>) - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenModel
- switchRpcThrottle(boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Switch the rpc throttle enable state.
- switchRpcThrottle(boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Switch the rpc throttle enabled state.
- switchRpcThrottle(boolean) - Method in class org.apache.hadoop.hbase.quotas.RegionServerRpcQuotaManager
- switchRpcThrottle(boolean) - Method in class org.apache.hadoop.hbase.quotas.RpcThrottleStorage
-
Store the rpc throttle value.
- switchRpcThrottle(MasterProtos.SwitchRpcThrottleRequest) - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
- switchRpcThrottle(RpcController, MasterProtos.SwitchRpcThrottleRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- switchSnapshotCleanup(RpcController, MasterProtos.SetSnapshotCleanupRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- switchSortOrder() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenModel
- switchSortOrder() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenPresenter
- switchToCryptoAES(CryptoAES) - Method in class org.apache.hadoop.hbase.security.HBaseSaslRpcServer
- switchZNode - 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.
- sync() - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
- sync() - Method in interface org.apache.hadoop.hbase.wal.WAL
-
Sync what we have in the WAL.
- sync(boolean) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
- sync(boolean) - Method in class org.apache.hadoop.hbase.regionserver.wal.AsyncProtobufLogWriter
- sync(boolean) - Method in class org.apache.hadoop.hbase.regionserver.wal.CombinedAsyncWriter
- sync(boolean) - Method in class org.apache.hadoop.hbase.regionserver.wal.CombinedWriter
- sync(boolean) - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogWriter
- sync(boolean) - Method in interface org.apache.hadoop.hbase.wal.WAL
- sync(boolean) - Method in interface org.apache.hadoop.hbase.wal.WALProvider.AsyncWriter
- sync(boolean) - Method in interface org.apache.hadoop.hbase.wal.WALProvider.Writer
- sync(long) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
- sync(long) - Method in interface org.apache.hadoop.hbase.wal.WAL
-
Sync the WAL if the txId was not already sync'd.
- sync(long, boolean) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
- sync(long, boolean) - Method in interface org.apache.hadoop.hbase.wal.WAL
- sync(String, AsyncCallback.VoidCallback, Object) - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
- SYNC - Enum constant in enum class org.apache.hadoop.hbase.regionserver.TimeRangeTracker.Type
- SYNC_OPERATION_LATENCY_DESC - Static variable in interface org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSource
- SYNC_OPERATION_LATENCY_NAME - Static variable in interface org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSource
- SYNC_REPLICATION_STATE_ZNODE - Static variable in class org.apache.hadoop.hbase.replication.ZKReplicationPeerStorage
- SYNC_TIME - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
- SYNC_TIME_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
- SYNC_TIMERANGE_TRACKER - Static variable in class org.apache.hadoop.hbase.util.ClassSize
-
Overhead for SyncTimeRangeTracker
- SYNC_WAL - Enum constant in enum class org.apache.hadoop.hbase.client.Durability
-
Write the Mutation to the WAL synchronously.
- SYNC_WAL_SUFFIX - Static variable in class org.apache.hadoop.hbase.replication.ReplicationUtils
- syncFutureCache - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
A cache of sync futures reused by threads.
- org.apache.hadoop.hbase.regionserver.wal.SyncFutureCache - Class in org.apache.hadoop.hbase.regionserver.wal
-
A cache of
SyncFuture
s. - SyncFutureCache(Configuration) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.SyncFutureCache
- syncFutures - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
- SyncMapper() - Constructor for class org.apache.hadoop.hbase.mapreduce.SyncTable.SyncMapper
- syncOrTimeout(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZKWatcher
-
Forces a synchronization of this ZooKeeper client connection within a timeout.
- org.apache.hadoop.hbase.replication.SyncReplicationState - Enum Class in org.apache.hadoop.hbase.replication
-
Used by synchronous replication.
- org.apache.hadoop.hbase.mapreduce.SyncTable - Class in org.apache.hadoop.hbase.mapreduce
- SyncTable(Configuration) - Constructor for class org.apache.hadoop.hbase.mapreduce.SyncTable
- org.apache.hadoop.hbase.mapreduce.SyncTable.SyncMapper - Class in org.apache.hadoop.hbase.mapreduce
- org.apache.hadoop.hbase.mapreduce.SyncTable.SyncMapper.Counter - Enum Class in org.apache.hadoop.hbase.mapreduce
- SYSTEM_CACHE_FLUSH_INTERVAL - Static variable in class org.apache.hadoop.hbase.regionserver.HRegion
-
Default interval for System tables memstore flush
- SYSTEM_NAMESPACE - Static variable in class org.apache.hadoop.hbase.NamespaceDescriptor
- SYSTEM_NAMESPACE_NAME - Static variable in class org.apache.hadoop.hbase.NamespaceDescriptor
-
System namespace name.
- SYSTEM_NAMESPACE_NAME_STR - Static variable in class org.apache.hadoop.hbase.NamespaceDescriptor
- SYSTEMTABLE_QOS - Static variable in class org.apache.hadoop.hbase.HConstants
- org.apache.hadoop.hbase.replication.SystemTableWALEntryFilter - Class in org.apache.hadoop.hbase.replication
-
Skips WAL edits for all System tables including hbase:meta except hbase:acl.
- SystemTableWALEntryFilter() - Constructor for class org.apache.hadoop.hbase.replication.SystemTableWALEntryFilter
T
- t - Variable in class org.apache.hadoop.hbase.util.HashKey
- Tab - Enum constant in enum class org.apache.hadoop.hbase.hbtop.terminal.KeyPress.Type
- TAB - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
ASCII code for tab
- table - Variable in class org.apache.hadoop.hbase.util.MultiThreadedReader.HBaseReaderThread
- table - Variable in class org.apache.hadoop.hbase.util.MultiThreadedUpdater.HBaseUpdaterThread
- org.apache.hadoop.hbase.client.Table - Interface in org.apache.hadoop.hbase.client
-
Used to communicate with a single HBase table.
- TABLE - Enum constant in enum class org.apache.hadoop.hbase.ClientMetaTableAccessor.QueryType
- TABLE - Enum constant in enum class org.apache.hadoop.hbase.hbtop.field.Field
- TABLE - Enum constant in enum class org.apache.hadoop.hbase.hbtop.mode.Mode
- TABLE - Enum constant in enum class org.apache.hadoop.hbase.regionserver.wal.CompressionContext.DictionaryIndex
- TABLE_DESC_PROP_GROUP - Static variable in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
- TABLE_FAMILY - Static variable in class org.apache.hadoop.hbase.HConstants
-
The catalog family
- TABLE_FAMILY_STR - Static variable in class org.apache.hadoop.hbase.HConstants
-
The catalog family as a string
- TABLE_INPUT_CLASS_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
- TABLE_MAP_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.WALPlayer
- TABLE_MAX_ROWSIZE_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
-
Default max row size (1 Gb).
- TABLE_MAX_ROWSIZE_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
Max size of single row for Get's or Scan's without in-row scanning flag set.
- TABLE_NAME - Static variable in class org.apache.hadoop.hbase.mapreduce.Import
- TABLE_NAME - Static variable in class org.apache.hadoop.hbase.PerformanceEvaluation
- TABLE_QUOTA_USAGE_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterQuotaSource
- TABLE_QUOTA_USAGE_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterQuotaSource
- TABLE_REGION_STATES_CACHE_TTL_MS - Static variable in class org.apache.hadoop.hbase.quotas.QuotaCache
- TABLE_SANITY_CHECKS - Static variable in class org.apache.hadoop.hbase.util.TableDescriptorChecker
- TABLE_SIZE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsTableSource
- TABLE_SIZE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsTableSource
- TABLE_STATE_QUALIFIER - Static variable in class org.apache.hadoop.hbase.HConstants
-
The serialized table state qualifier
- TABLE_TO_REGIONS_COUNT - Enum constant in enum class org.apache.hadoop.hbase.ClusterMetrics.Option
-
metrics about table to no of regions status count
- org.apache.hadoop.hbase.client.Table.CheckAndMutateBuilder - Interface in org.apache.hadoop.hbase.client
-
Deprecated.Since 3.0.0, will be removed in 4.0.0. For internal test use only, do not use it any more.
- org.apache.hadoop.hbase.client.Table.CheckAndMutateWithFilterBuilder - Interface in org.apache.hadoop.hbase.client
-
Deprecated.Since 3.0.0, will be removed in 4.0.0. For internal test use only, do not use it any more.
- org.apache.hadoop.hbase.client.TableBuilder - Interface in org.apache.hadoop.hbase.client
-
For creating
Table
instance. - org.apache.hadoop.hbase.client.replication.TableCFs - Class in org.apache.hadoop.hbase.client.replication
-
Used by
Admin.listReplicatedTableCFs()
. - TableCFs(TableName, Map<String, Integer>) - Constructor for class org.apache.hadoop.hbase.client.replication.TableCFs
- org.apache.hadoop.hbase.client.TableDescriptor - Interface in org.apache.hadoop.hbase.client
-
TableDescriptor contains the details about an HBase table such as the descriptors of all the column families, is the table a catalog table,
hbase:meta
, if the table is read only, the maximum size of the memstore, when the region split should occur, coprocessors associated with it etc... - org.apache.hadoop.hbase.client.TableDescriptorBuilder - Class in org.apache.hadoop.hbase.client
-
Convenience class for composing an instance of
TableDescriptor
. - org.apache.hadoop.hbase.util.TableDescriptorChecker - Class in org.apache.hadoop.hbase.util
-
Only used for master to sanity check
TableDescriptor
. - tableDescriptors - Variable in class org.apache.hadoop.hbase.HBaseServerBase
-
Go here to get table descriptors.
- org.apache.hadoop.hbase.TableDescriptors - Interface in org.apache.hadoop.hbase
-
Get, remove and modify table descriptors.
- org.apache.hadoop.hbase.client.TableDescriptorUtils - Class in org.apache.hadoop.hbase.client
- org.apache.hadoop.hbase.client.TableDescriptorUtils.TableDescriptorDelta - Class in org.apache.hadoop.hbase.client
- tableExists(AsyncTable<?>, TableName) - Static method in class org.apache.hadoop.hbase.ClientMetaTableAccessor
- tableExists(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Check if a table exists.
- tableExists(TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Check if a table exists.
- org.apache.hadoop.hbase.TableExistsException - Exception in org.apache.hadoop.hbase
-
Thrown when a table exists but should not.
- TableExistsException() - Constructor for exception org.apache.hadoop.hbase.TableExistsException
- TableExistsException(String) - Constructor for exception org.apache.hadoop.hbase.TableExistsException
- TableExistsException(TableName) - Constructor for exception org.apache.hadoop.hbase.TableExistsException
- tableFilterParams(NormalizeTableFilterParams) - Method in class org.apache.hadoop.hbase.client.NormalizeTableFilterParams.Builder
- tableHasErrors(HbckTableInfo) - Method in interface org.apache.hadoop.hbase.util.HbckErrorReporter
-
Deprecated.
- TableHash() - Constructor for class org.apache.hadoop.hbase.mapreduce.HashTable.TableHash
- TABLEINFO_DIR - Static variable in class org.apache.hadoop.hbase.util.FSTableDescriptors
- org.apache.hadoop.hbase.TableInfoMissingException - Exception in org.apache.hadoop.hbase
-
Failed to find
.tableinfo
file under the table directory. - TableInfoMissingException() - Constructor for exception org.apache.hadoop.hbase.TableInfoMissingException
-
Failed to find
.tableinfo
file under the table directory. - TableInfoMissingException(String) - Constructor for exception org.apache.hadoop.hbase.TableInfoMissingException
- TableInfoMissingException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.TableInfoMissingException
- TableInfoMissingException(Throwable) - Constructor for exception org.apache.hadoop.hbase.TableInfoMissingException
- org.apache.hadoop.hbase.mapred.TableInputFormat - Class in org.apache.hadoop.hbase.mapred
-
Convert HBase tabular data into a format that is consumable by Map/Reduce.
- org.apache.hadoop.hbase.mapreduce.TableInputFormat - Class in org.apache.hadoop.hbase.mapreduce
-
Convert HBase tabular data into a format that is consumable by Map/Reduce.
- TableInputFormat() - Constructor for class org.apache.hadoop.hbase.mapred.TableInputFormat
- TableInputFormat() - Constructor for class org.apache.hadoop.hbase.mapreduce.TableInputFormat
- org.apache.hadoop.hbase.mapred.TableInputFormatBase - Class in org.apache.hadoop.hbase.mapred
-
A Base for
TableInputFormat
s. - org.apache.hadoop.hbase.mapreduce.TableInputFormatBase - Class in org.apache.hadoop.hbase.mapreduce
-
A base for
TableInputFormat
s. - TableInputFormatBase() - Constructor for class org.apache.hadoop.hbase.mapred.TableInputFormatBase
- TableInputFormatBase() - Constructor for class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
- org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandler - Interface in org.apache.hadoop.hbase.util.hbck
-
This interface provides callbacks for handling particular table integrity invariant violations.
- org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandlerImpl - Class in org.apache.hadoop.hbase.util.hbck
-
Simple implementation of TableIntegrityErrorHandler.
- TableIntegrityErrorHandlerImpl() - Constructor for class org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandlerImpl
- tableLock(TableName, boolean, String, Abortable) - Method in class org.apache.hadoop.hbase.client.locking.LockServiceClient
-
Create a new EntityLock object to acquire an exclusive or shared lock on a table.
- org.apache.hadoop.hbase.mapred.TableMap<K extends org.apache.hadoop.io.WritableComparable<? super K>,
V> - Interface in org.apache.hadoop.hbase.mapred -
Scan an HBase table to sort by a specified sort column.
- org.apache.hadoop.hbase.mapreduce.TableMapper<KEYOUT,
VALUEOUT> - Class in org.apache.hadoop.hbase.mapreduce -
Extends the base
Mapper
class to add the required input key and value classes. - TableMapper() - Constructor for class org.apache.hadoop.hbase.mapreduce.TableMapper
- org.apache.hadoop.hbase.mapred.TableMapReduceUtil - Class in org.apache.hadoop.hbase.mapred
-
Utility for
TableMap
andTableReduce
- org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil - Class in org.apache.hadoop.hbase.mapreduce
-
Utility for
TableMapper
andTableReducer
- TableMapReduceUtil() - Constructor for class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
- TableMapReduceUtil() - Constructor for class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
- TableMetricsWrapperRunnable() - Constructor for class org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImpl.TableMetricsWrapperRunnable
- org.apache.hadoop.hbase.hbtop.mode.TableModeStrategy - Class in org.apache.hadoop.hbase.hbtop.mode
-
Implementation for
ModeStrategy
for Table Mode. - tableName - Variable in class org.apache.hadoop.hbase.util.compaction.MajorCompactor
- tableName - Variable in class org.apache.hadoop.hbase.util.MultiThreadedAction
- org.apache.hadoop.hbase.TableName - Class in org.apache.hadoop.hbase
-
Immutable POJO class for representing a table name.
- TABLENAME_DELIMITER_IN_COMMAND - Static variable in interface org.apache.hadoop.hbase.backup.BackupRestoreConstants
- tableNames(List<TableName>) - Method in class org.apache.hadoop.hbase.client.NormalizeTableFilterParams.Builder
- org.apache.hadoop.hbase.master.TableNamespaceManager - Class in org.apache.hadoop.hbase.master
-
This is a helper class used internally to manage the namespace metadata that is stored in the ns family in meta table.
- org.apache.hadoop.hbase.TableNotDisabledException - Exception in org.apache.hadoop.hbase
-
Thrown if a table should be offline but is not.
- TableNotDisabledException() - Constructor for exception org.apache.hadoop.hbase.TableNotDisabledException
- TableNotDisabledException(byte[]) - Constructor for exception org.apache.hadoop.hbase.TableNotDisabledException
- TableNotDisabledException(String) - Constructor for exception org.apache.hadoop.hbase.TableNotDisabledException
- TableNotDisabledException(TableName) - Constructor for exception org.apache.hadoop.hbase.TableNotDisabledException
- org.apache.hadoop.hbase.TableNotEnabledException - Exception in org.apache.hadoop.hbase
-
Thrown if a table should be enabled but is not.
- TableNotEnabledException() - Constructor for exception org.apache.hadoop.hbase.TableNotEnabledException
-
default constructor
- TableNotEnabledException(byte[]) - Constructor for exception org.apache.hadoop.hbase.TableNotEnabledException
- TableNotEnabledException(String) - Constructor for exception org.apache.hadoop.hbase.TableNotEnabledException
- TableNotEnabledException(TableName) - Constructor for exception org.apache.hadoop.hbase.TableNotEnabledException
- org.apache.hadoop.hbase.TableNotFoundException - Exception in org.apache.hadoop.hbase
-
Thrown when a table cannot be located.
- TableNotFoundException() - Constructor for exception org.apache.hadoop.hbase.TableNotFoundException
- TableNotFoundException(byte[]) - Constructor for exception org.apache.hadoop.hbase.TableNotFoundException
- TableNotFoundException(String) - Constructor for exception org.apache.hadoop.hbase.TableNotFoundException
- TableNotFoundException(TableName) - Constructor for exception org.apache.hadoop.hbase.TableNotFoundException
- org.apache.hadoop.hbase.client.trace.TableOperationSpanBuilder - Class in org.apache.hadoop.hbase.client.trace
-
Construct
Span
instances originating from "table operations" -- the verbs in our public API that interact with data in tables. - TableOperationSpanBuilder(AsyncConnectionImpl) - Constructor for class org.apache.hadoop.hbase.client.trace.TableOperationSpanBuilder
- org.apache.hadoop.hbase.mapreduce.TableOutputCommitter - Class in org.apache.hadoop.hbase.mapreduce
-
Small committer class that does not do anything.
- TableOutputCommitter() - Constructor for class org.apache.hadoop.hbase.mapreduce.TableOutputCommitter
- org.apache.hadoop.hbase.mapred.TableOutputFormat - Class in org.apache.hadoop.hbase.mapred
-
Convert Map/Reduce output and write it to an HBase table
- org.apache.hadoop.hbase.mapreduce.TableOutputFormat<KEY> - Class in org.apache.hadoop.hbase.mapreduce
-
Convert Map/Reduce output and write it to an HBase table.
- TableOutputFormat() - Constructor for class org.apache.hadoop.hbase.mapred.TableOutputFormat
- TableOutputFormat() - Constructor for class org.apache.hadoop.hbase.mapreduce.TableOutputFormat
- org.apache.hadoop.hbase.mapred.TableOutputFormat.TableRecordWriter - Class in org.apache.hadoop.hbase.mapred
-
Convert Reduce output (key, value) to (HStoreKey, KeyedDataArrayWritable) and write to an HBase table.
- org.apache.hadoop.hbase.mapreduce.TableOutputFormat.TableRecordWriter - Class in org.apache.hadoop.hbase.mapreduce
-
Writes the reducer output to an HBase table.
- org.apache.hadoop.hbase.snapshot.TablePartiallyOpenException - Exception in org.apache.hadoop.hbase.snapshot
-
Thrown if a table should be online/offline, but is partially open.
- TablePartiallyOpenException() - Constructor for exception org.apache.hadoop.hbase.snapshot.TablePartiallyOpenException
-
Constructs an
TablePartiallyOpenException
withnull
as its error detail message. - TablePartiallyOpenException(byte[]) - Constructor for exception org.apache.hadoop.hbase.snapshot.TablePartiallyOpenException
- TablePartiallyOpenException(String) - Constructor for exception org.apache.hadoop.hbase.snapshot.TablePartiallyOpenException
- TablePartiallyOpenException(TableName) - Constructor for exception org.apache.hadoop.hbase.snapshot.TablePartiallyOpenException
- org.apache.hadoop.hbase.quotas.TableQuotaSnapshotStore - Class in org.apache.hadoop.hbase.quotas
-
QuotaSnapshotStore
for tables. - TableQuotaSnapshotStore(Connection, QuotaObserverChore, Map<RegionInfo, Long>) - Constructor for class org.apache.hadoop.hbase.quotas.TableQuotaSnapshotStore
- org.apache.hadoop.hbase.mapred.TableRecordReader - Class in org.apache.hadoop.hbase.mapred
-
Iterate over an HBase table data, return (Text, RowResult) pairs
- org.apache.hadoop.hbase.mapreduce.TableRecordReader - Class in org.apache.hadoop.hbase.mapreduce
-
Iterate over an HBase table data, return (ImmutableBytesWritable, Result) pairs.
- TableRecordReader() - Constructor for class org.apache.hadoop.hbase.mapred.TableRecordReader
- TableRecordReader() - Constructor for class org.apache.hadoop.hbase.mapreduce.TableRecordReader
- org.apache.hadoop.hbase.mapred.TableRecordReaderImpl - Class in org.apache.hadoop.hbase.mapred
-
Iterate over an HBase table data, return (Text, RowResult) pairs
- org.apache.hadoop.hbase.mapreduce.TableRecordReaderImpl - Class in org.apache.hadoop.hbase.mapreduce
-
Iterate over an HBase table data, return (ImmutableBytesWritable, Result) pairs.
- TableRecordReaderImpl() - Constructor for class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
- TableRecordReaderImpl() - Constructor for class org.apache.hadoop.hbase.mapreduce.TableRecordReaderImpl
- TableRecordWriter() - Constructor for class org.apache.hadoop.hbase.mapreduce.TableOutputFormat.TableRecordWriter
- TableRecordWriter(JobConf) - Constructor for class org.apache.hadoop.hbase.mapred.TableOutputFormat.TableRecordWriter
-
Instantiate a TableRecordWriter with a BufferedMutator for batch writing.
- org.apache.hadoop.hbase.mapred.TableReduce<K extends org.apache.hadoop.io.WritableComparable,
V> - Interface in org.apache.hadoop.hbase.mapred -
Write a table, sorting by the input key
- org.apache.hadoop.hbase.mapreduce.TableReducer<KEYIN,
VALUEIN, KEYOUT> - Class in org.apache.hadoop.hbase.mapreduce -
Extends the basic
Reducer
class to add the required key and value input/output classes. - TableReducer() - Constructor for class org.apache.hadoop.hbase.mapreduce.TableReducer
- org.apache.hadoop.hbase.replication.TableReplicationQueueStorage - Class in org.apache.hadoop.hbase.replication
-
HBase table based replication queue storage.
- TableReplicationQueueStorage(Connection, TableName) - Constructor for class org.apache.hadoop.hbase.replication.TableReplicationQueueStorage
- org.apache.hadoop.hbase.rest.TableResource - Class in org.apache.hadoop.hbase.rest
- TableResource(String) - Constructor for class org.apache.hadoop.hbase.rest.TableResource
-
Constructor
- TABLES_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.WALPlayer
- org.apache.hadoop.hbase.rest.TableScanResource - Class in org.apache.hadoop.hbase.rest
- TableScanResource(ResultScanner, int) - Constructor for class org.apache.hadoop.hbase.rest.TableScanResource
- org.apache.hadoop.hbase.rest.TableScanResource.CellSetModelStream - Class in org.apache.hadoop.hbase.rest
- tableSeparator - Static variable in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
- tableSeparator - Static variable in class org.apache.hadoop.hbase.mapreduce.WALPlayer
- org.apache.hadoop.hbase.mapred.TableSnapshotInputFormat - Class in org.apache.hadoop.hbase.mapred
-
TableSnapshotInputFormat allows a MapReduce job to run over a table snapshot.
- org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormat - Class in org.apache.hadoop.hbase.mapreduce
-
TableSnapshotInputFormat allows a MapReduce job to run over a table snapshot.
- TableSnapshotInputFormat() - Constructor for class org.apache.hadoop.hbase.mapred.TableSnapshotInputFormat
- TableSnapshotInputFormat() - Constructor for class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormat
- org.apache.hadoop.hbase.mapred.TableSnapshotInputFormat.TableSnapshotRegionSplit - Class in org.apache.hadoop.hbase.mapred
- org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormat.TableSnapshotRegionSplit - Class in org.apache.hadoop.hbase.mapreduce
- org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl - Class in org.apache.hadoop.hbase.mapreduce
-
Hadoop MR API-agnostic implementation for mapreduce over table snapshots.
- TableSnapshotInputFormatImpl() - Constructor for class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl
- org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.InputSplit - Class in org.apache.hadoop.hbase.mapreduce
-
Implementation class for InputSplit logic common between mapred and mapreduce.
- org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.RecordReader - Class in org.apache.hadoop.hbase.mapreduce
-
Implementation class for RecordReader logic common between mapred and mapreduce.
- TableSnapshotRegionSplit() - Constructor for class org.apache.hadoop.hbase.mapred.TableSnapshotInputFormat.TableSnapshotRegionSplit
- TableSnapshotRegionSplit() - Constructor for class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormat.TableSnapshotRegionSplit
- TableSnapshotRegionSplit(TableDescriptor, RegionInfo, List<String>, Scan, Path) - Constructor for class org.apache.hadoop.hbase.mapred.TableSnapshotInputFormat.TableSnapshotRegionSplit
- TableSnapshotRegionSplit(TableDescriptor, RegionInfo, List<String>, Scan, Path) - Constructor for class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormat.TableSnapshotRegionSplit
- TableSnapshotRegionSplit(TableSnapshotInputFormatImpl.InputSplit) - Constructor for class org.apache.hadoop.hbase.mapred.TableSnapshotInputFormat.TableSnapshotRegionSplit
- TableSnapshotRegionSplit(TableSnapshotInputFormatImpl.InputSplit) - Constructor for class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormat.TableSnapshotRegionSplit
- org.apache.hadoop.hbase.client.TableSnapshotScanner - Class in org.apache.hadoop.hbase.client
-
A Scanner which performs a scan over snapshot files.
- TableSnapshotScanner(Configuration, Path, String, Scan) - Constructor for class org.apache.hadoop.hbase.client.TableSnapshotScanner
-
Creates a TableSnapshotScanner.
- TableSnapshotScanner(Configuration, Path, Path, String, Scan) - Constructor for class org.apache.hadoop.hbase.client.TableSnapshotScanner
- TableSnapshotScanner(Configuration, Path, Path, String, Scan, boolean) - Constructor for class org.apache.hadoop.hbase.client.TableSnapshotScanner
-
Creates a TableSnapshotScanner.
- org.apache.hadoop.hbase.quotas.TableSpaceQuotaSnapshotNotifier - Class in org.apache.hadoop.hbase.quotas
-
A
SpaceQuotaSnapshotNotifier
which uses the hbase:quota table. - TableSpaceQuotaSnapshotNotifier() - Constructor for class org.apache.hadoop.hbase.quotas.TableSpaceQuotaSnapshotNotifier
- org.apache.hadoop.hbase.client.trace.TableSpanBuilder - Class in org.apache.hadoop.hbase.client.trace
-
Construct
Span
instances involving data tables. - TableSpanBuilder(AsyncConnectionImpl) - Constructor for class org.apache.hadoop.hbase.client.trace.TableSpanBuilder
- org.apache.hadoop.hbase.mapred.TableSplit - Class in org.apache.hadoop.hbase.mapred
-
A table split corresponds to a key range [low, high)
- org.apache.hadoop.hbase.mapreduce.TableSplit - Class in org.apache.hadoop.hbase.mapreduce
-
A table split corresponds to a key range (low, high) and an optional scanner.
- TableSplit() - Constructor for class org.apache.hadoop.hbase.mapred.TableSplit
-
default constructor
- TableSplit() - Constructor for class org.apache.hadoop.hbase.mapreduce.TableSplit
-
Default constructor.
- TableSplit(byte[], byte[], byte[], String) - Constructor for class org.apache.hadoop.hbase.mapred.TableSplit
- TableSplit(TableName, byte[], byte[], String) - Constructor for class org.apache.hadoop.hbase.mapred.TableSplit
-
Constructor
- TableSplit(TableName, byte[], byte[], String) - Constructor for class org.apache.hadoop.hbase.mapreduce.TableSplit
-
Creates a new instance without a scanner.
- TableSplit(TableName, byte[], byte[], String, long) - Constructor for class org.apache.hadoop.hbase.mapreduce.TableSplit
-
Creates a new instance without a scanner.
- TableSplit(TableName, Scan, byte[], byte[], String) - Constructor for class org.apache.hadoop.hbase.mapreduce.TableSplit
-
Creates a new instance while assigning all variables.
- TableSplit(TableName, Scan, byte[], byte[], String, long) - Constructor for class org.apache.hadoop.hbase.mapreduce.TableSplit
-
Creates a new instance while assigning all variables.
- TableSplit(TableName, Scan, byte[], byte[], String, String, long) - Constructor for class org.apache.hadoop.hbase.mapreduce.TableSplit
-
Creates a new instance while assigning all variables.
- org.apache.hadoop.hbase.client.TableState - Class in org.apache.hadoop.hbase.client
-
Represents table state.
- TableState(TableName, TableState.State) - Constructor for class org.apache.hadoop.hbase.client.TableState
-
Create instance of TableState.
- org.apache.hadoop.hbase.client.TableState.State - Enum Class in org.apache.hadoop.hbase.client
- org.apache.hadoop.hbase.master.TableStateManager - Class in org.apache.hadoop.hbase.master
-
This is a helper class used to manage table states.
- tableZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZNodePaths
-
Deprecated.
- tag(String, String, String) - Static method in class org.apache.hadoop.hbase.metrics.Interns
-
Get a metrics tag
- tag(MetricsInfo, String) - Static method in class org.apache.hadoop.hbase.metrics.Interns
-
Get a metrics tag
- org.apache.hadoop.hbase.Tag - Interface in org.apache.hadoop.hbase
-
Tags are part of cells and helps to add metadata about them.
- TAG_LENGTH_SIZE - Static variable in interface org.apache.hadoop.hbase.Tag
- org.apache.hadoop.hbase.TagBuilder - Interface in org.apache.hadoop.hbase
-
Builder implementation to create
Tag
Call setTagValue(byte[]) method to createArrayBackedTag
- org.apache.hadoop.hbase.TagBuilderFactory - Class in org.apache.hadoop.hbase
-
Factory to create Tags.
- TagBuilderFactory() - Constructor for class org.apache.hadoop.hbase.TagBuilderFactory
- org.apache.hadoop.hbase.io.TagCompressionContext - Class in org.apache.hadoop.hbase.io
-
Context that holds the dictionary for Tag compression and doing the compress/uncompress.
- TagCompressionContext(Class<? extends Dictionary>, int) - Constructor for class org.apache.hadoop.hbase.io.TagCompressionContext
- tags - Variable in class org.apache.hadoop.hbase.ExtendedCellBuilderImpl
- TAGS_LENGTH_SIZE - Static variable in class org.apache.hadoop.hbase.KeyValue
-
Size of the tags length field in bytes
- tagsIterator(ByteBuffer, int, int) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
- tagsIterator(ExtendedCell) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
Utility method to iterate through the tags in the given cell.
- tagsLength - Variable in class org.apache.hadoop.hbase.ExtendedCellBuilderImpl
- tagsOffset - Variable in class org.apache.hadoop.hbase.ExtendedCellBuilderImpl
- tagsPresent - Variable in class org.apache.hadoop.hbase.regionserver.Segment
- org.apache.hadoop.hbase.TagType - Class in org.apache.hadoop.hbase
- TagType() - Constructor for class org.apache.hadoop.hbase.TagType
- org.apache.hadoop.hbase.TagUtil - Class in org.apache.hadoop.hbase
- tail(byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Make a new byte array from a subset of bytes at the tail of another.
- tailMap(byte[]) - Method in class org.apache.hadoop.hbase.io.hfile.HFileInfo
- tailMap(K) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
- tailMap(K, boolean) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
- tailMap(T) - Method in class org.apache.hadoop.hbase.regionserver.CellFlatMap
- tailMap(T, boolean) - Method in class org.apache.hadoop.hbase.regionserver.CellFlatMap
- tailSet(ExtendedCell) - Method in class org.apache.hadoop.hbase.regionserver.CompositeImmutableSegment
-
Returns a subset of the segment cell set, which starts with the given cell
- tailSet(ExtendedCell) - Method in class org.apache.hadoop.hbase.regionserver.Segment
-
Returns a subset of the segment cell set, which starts with the given cell
- tailSet(T) - Method in class org.apache.hadoop.hbase.regionserver.CellSet
- tailSet(T, boolean) - Method in class org.apache.hadoop.hbase.regionserver.CellSet
- take() - Method in class org.apache.hadoop.hbase.ipc.AdaptiveLifoCoDelCallQueue
-
Behaves as
LinkedBlockingQueue.take()
, except it will silently skip all calls which it thinks should be dropped. - take() - Method in class org.apache.hadoop.hbase.thrift.CallQueue
- take() - Method in class org.apache.hadoop.hbase.util.BoundedCompletionService
- take() - Method in class org.apache.hadoop.hbase.util.BoundedPriorityBlockingQueue
- take() - Method in class org.apache.hadoop.hbase.util.StealJobQueue
- TARGETMISSINGCELLS - Enum constant in enum class org.apache.hadoop.hbase.mapreduce.SyncTable.SyncMapper.Counter
- TARGETMISSINGROWS - Enum constant in enum class org.apache.hadoop.hbase.mapreduce.SyncTable.SyncMapper.Counter
- targetReplicaId - Variable in class org.apache.hadoop.hbase.client.Query
- Task() - Constructor for class org.apache.hadoop.hbase.master.SplitLogManager.Task
-
Deprecated.
- TASK_COMPLETION_STRING - Static variable in class org.apache.hadoop.hbase.chaos.ChaosConstants
- TASK_ERROR_STRING - Static variable in class org.apache.hadoop.hbase.chaos.ChaosConstants
- TaskBatch() - Constructor for class org.apache.hadoop.hbase.master.SplitLogManager.TaskBatch
-
Deprecated.
- taskLoop() - Method in interface org.apache.hadoop.hbase.coordination.SplitLogWorkerCoordination
-
Deprecated.Wait for the new tasks and grab one
- taskLoop() - Method in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination
-
Wait for tasks to become available at /hbase/splitlog zknode.
- TASKS - Enum constant in enum class org.apache.hadoop.hbase.ClusterMetrics.Option
-
metrics about monitored tasks
- tasksInProgress - Variable in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination
- TB_IN_BYTES - Static variable in class org.apache.hadoop.hbase.HConstants
- org.apache.hadoop.hbase.thrift.TBoundedThreadPoolServer - Class in org.apache.hadoop.hbase.thrift
-
A bounded thread pool server customized for HBase.
- TBoundedThreadPoolServer(TBoundedThreadPoolServer.Args, ThriftMetrics) - Constructor for class org.apache.hadoop.hbase.thrift.TBoundedThreadPoolServer
- org.apache.hadoop.hbase.thrift.TBoundedThreadPoolServer.Args - Class in org.apache.hadoop.hbase.thrift
- tcpKeepAlive - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
- tcpKeepAlive - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
- tcpNoDelay - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
- tcpNoDelay - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
- TEMP_DIR_NAME - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
- TEMPORARY_FS_DIRECTORY_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
Config key for hbase temporary directory in hdfs
- TERABYTE - Enum constant in enum class org.apache.hadoop.hbase.Size.Unit
- term - Variable in class org.apache.hadoop.hbase.types.TerminatedWrapper
- org.apache.hadoop.hbase.hbtop.terminal.Terminal - Interface in org.apache.hadoop.hbase.hbtop.terminal
-
The terminal interface that is an abstraction of terminal screen.
- org.apache.hadoop.hbase.hbtop.terminal.impl.TerminalImpl - Class in org.apache.hadoop.hbase.hbtop.terminal.impl
-
An implementation of the
Terminal
interface for normal display mode. - TerminalImpl() - Constructor for class org.apache.hadoop.hbase.hbtop.terminal.impl.TerminalImpl
- TerminalImpl(String) - Constructor for class org.apache.hadoop.hbase.hbtop.terminal.impl.TerminalImpl
- org.apache.hadoop.hbase.hbtop.terminal.TerminalPrinter - Interface in org.apache.hadoop.hbase.hbtop.terminal
-
The interface responsible for printing to the terminal.
- org.apache.hadoop.hbase.hbtop.terminal.impl.TerminalPrinterImpl - Class in org.apache.hadoop.hbase.hbtop.terminal.impl
-
An implementation of the
TerminalPrinter
interface for normal display mode. - org.apache.hadoop.hbase.hbtop.terminal.TerminalSize - Class in org.apache.hadoop.hbase.hbtop.terminal
-
Terminal dimensions in 2-d space, measured in number of rows and columns.
- TerminalSize(int, int) - Constructor for class org.apache.hadoop.hbase.hbtop.terminal.TerminalSize
- terminate() - Method in interface org.apache.hadoop.hbase.client.AdvancedScanResultConsumer.ScanController
-
Terminate the scan.
- org.apache.hadoop.hbase.types.TerminatedWrapper<T> - Class in org.apache.hadoop.hbase.types
-
Wraps an existing
DataType
implementation as a terminated version of itself. - TerminatedWrapper(DataType<T>, byte[]) - Constructor for class org.apache.hadoop.hbase.types.TerminatedWrapper
-
Create a terminated version of the
wrapped
. - TerminatedWrapper(DataType<T>, String) - Constructor for class org.apache.hadoop.hbase.types.TerminatedWrapper
-
Create a terminated version of the
wrapped
. - terminatorPosition(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.TerminatedWrapper
-
Return the position at which
term
begins withinsrc
, or-1
ifterm
is not found. - TERTIARY - Enum constant in enum class org.apache.hadoop.hbase.favored.FavoredNodesPlan.Position
- TEST_CONF - Static variable in class org.apache.hadoop.hbase.security.User.TestingGroups
- TEST_SKIP_REPORTING_TRANSITION - Static variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
For testing only! Set to true to skip notifying region assignment to master .
- testCipherProvider(Configuration) - Static method in class org.apache.hadoop.hbase.util.EncryptionTest
-
Check that the configured cipher provider can be loaded and initialized, or throw an exception.
- testCompression(String) - Static method in class org.apache.hadoop.hbase.util.CompressionTest
- testCompression(Compression.Algorithm) - Static method in class org.apache.hadoop.hbase.util.CompressionTest
- testEncryption(Configuration, String, byte[]) - Static method in class org.apache.hadoop.hbase.util.EncryptionTest
-
Check that the specified cipher can be loaded and initialized, or throw an exception.
- testHdfsStreaming(Path) - Method in class org.apache.hadoop.hbase.ScanPerformanceEvaluation
- TestingGroups(Groups) - Constructor for class org.apache.hadoop.hbase.security.User.TestingGroups
- org.apache.hadoop.hbase.testing.TestingHBaseCluster - Interface in org.apache.hadoop.hbase.testing
-
A mini hbase cluster used for testing.
- org.apache.hadoop.hbase.testing.TestingHBaseClusterOption - Class in org.apache.hadoop.hbase.testing
-
Options for starting up a mini testing cluster
TestingHBaseCluster
(including an hbase, dfs and zookeeper clusters) in test. - org.apache.hadoop.hbase.testing.TestingHBaseClusterOption.Builder - Class in org.apache.hadoop.hbase.testing
-
Builder pattern for creating an
TestingHBaseClusterOption
. - testKeyProvider(Configuration) - Static method in class org.apache.hadoop.hbase.util.EncryptionTest
-
Check that the configured key provider can be loaded and initialized, or throw an exception.
- testScan() - Method in class org.apache.hadoop.hbase.ScanPerformanceEvaluation
- testScanMapReduce() - Method in class org.apache.hadoop.hbase.ScanPerformanceEvaluation
- testSnapshotScan() - Method in class org.apache.hadoop.hbase.ScanPerformanceEvaluation
- testSnapshotScanMapReduce() - Method in class org.apache.hadoop.hbase.ScanPerformanceEvaluation
- testTableCoprocessorAttrs(Configuration, TableDescriptor) - Static method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
Sanity check the table coprocessor attributes of the supplied schema.
- org.apache.hadoop.hbase.mapreduce.TextSortReducer - Class in org.apache.hadoop.hbase.mapreduce
-
Emits Sorted KeyValues.
- TextSortReducer() - Constructor for class org.apache.hadoop.hbase.mapreduce.TextSortReducer
- org.apache.hadoop.hbase.thrift.THBaseThreadPoolExecutor - Class in org.apache.hadoop.hbase.thrift
-
A ThreadPoolExecutor customized for working with HBase thrift to update metrics before and after the execution of a task.
- THBaseThreadPoolExecutor(int, int, long, TimeUnit, BlockingQueue<Runnable>, ThreadFactory, ThriftMetrics) - Constructor for class org.apache.hadoop.hbase.thrift.THBaseThreadPoolExecutor
- THBaseThreadPoolExecutor(int, int, long, TimeUnit, BlockingQueue<Runnable>, ThriftMetrics) - Constructor for class org.apache.hadoop.hbase.thrift.THBaseThreadPoolExecutor
- thenDelete(Delete) - Method in interface org.apache.hadoop.hbase.client.AsyncTable.CheckAndMutateBuilder
-
Deprecated.Specify a Delete to commit if the check succeeds.
- thenDelete(Delete) - Method in interface org.apache.hadoop.hbase.client.AsyncTable.CheckAndMutateWithFilterBuilder
-
Deprecated.Specify a Delete to commit if the check succeeds.
- thenDelete(Delete) - Method in interface org.apache.hadoop.hbase.client.Table.CheckAndMutateBuilder
-
Deprecated.Specify a Delete to commit if the check succeeds.
- thenDelete(Delete) - Method in interface org.apache.hadoop.hbase.client.Table.CheckAndMutateWithFilterBuilder
-
Deprecated.Specify a Delete to commit if the check succeeds.
- thenMutate(RowMutations) - Method in interface org.apache.hadoop.hbase.client.AsyncTable.CheckAndMutateBuilder
-
Deprecated.Specify a RowMutations to commit if the check succeeds.
- thenMutate(RowMutations) - Method in interface org.apache.hadoop.hbase.client.AsyncTable.CheckAndMutateWithFilterBuilder
-
Deprecated.Specify a RowMutations to commit if the check succeeds.
- thenMutate(RowMutations) - Method in interface org.apache.hadoop.hbase.client.Table.CheckAndMutateBuilder
-
Deprecated.Specify a RowMutations to commit if the check succeeds.
- thenMutate(RowMutations) - Method in interface org.apache.hadoop.hbase.client.Table.CheckAndMutateWithFilterBuilder
-
Deprecated.Specify a RowMutations to commit if the check succeeds.
- thenPut(Put) - Method in interface org.apache.hadoop.hbase.client.AsyncTable.CheckAndMutateBuilder
-
Deprecated.Specify a Put to commit if the check succeeds.
- thenPut(Put) - Method in interface org.apache.hadoop.hbase.client.AsyncTable.CheckAndMutateWithFilterBuilder
-
Deprecated.Specify a Put to commit if the check succeeds.
- thenPut(Put) - Method in interface org.apache.hadoop.hbase.client.Table.CheckAndMutateBuilder
-
Deprecated.Specify a Put to commit if the check succeeds.
- thenPut(Put) - Method in interface org.apache.hadoop.hbase.client.Table.CheckAndMutateWithFilterBuilder
-
Deprecated.Specify a Put to commit if the check succeeds.
- THREAD_KEEP_ALIVE_TIME_SEC_CONF_KEY - Static variable in class org.apache.hadoop.hbase.thrift.TBoundedThreadPoolServer
-
Default amount of time in seconds to keep a thread alive.
- THREAD_POOL - Enum constant in enum class org.apache.hadoop.hbase.thrift.ImplType
- THREAD_WAKE_FREQUENCY - Static variable in class org.apache.hadoop.hbase.HConstants
-
Parameter name for how often threads should wake up
- threadDumpingIsAlive(Thread) - Static method in class org.apache.hadoop.hbase.util.Threads
-
Waits on the passed thread to die dumping a threaddump every minute while its up.
- THREADED_SELECTOR - Enum constant in enum class org.apache.hadoop.hbase.thrift.ImplType
- ThreadLocal - Enum constant in enum class org.apache.hadoop.hbase.util.PoolMap.PoolType
- org.apache.hadoop.hbase.util.Threads - Class in org.apache.hadoop.hbase.util
-
Thread Utility
- Threads() - Constructor for class org.apache.hadoop.hbase.util.Threads
- THRIFT_CALL_KEY - Static variable in interface org.apache.hadoop.hbase.thrift.MetricsThriftServerSource
- THRIFT_DNS_INTERFACE_KEY - Static variable in class org.apache.hadoop.hbase.thrift.Constants
- THRIFT_DNS_NAMESERVER_KEY - Static variable in class org.apache.hadoop.hbase.thrift.Constants
- THRIFT_FILTERS - Static variable in class org.apache.hadoop.hbase.thrift.Constants
- THRIFT_HTTP_ALLOW_OPTIONS_METHOD - Static variable in class org.apache.hadoop.hbase.thrift.Constants
- THRIFT_HTTP_ALLOW_OPTIONS_METHOD_DEFAULT - Static variable in class org.apache.hadoop.hbase.thrift.Constants
- THRIFT_INFO_SERVER_BINDING_ADDRESS - Static variable in class org.apache.hadoop.hbase.thrift.Constants
- THRIFT_INFO_SERVER_BINDING_ADDRESS_DEFAULT - Static variable in class org.apache.hadoop.hbase.thrift.Constants
- THRIFT_INFO_SERVER_PORT - Static variable in class org.apache.hadoop.hbase.thrift.Constants
- THRIFT_INFO_SERVER_PORT_DEFAULT - Static variable in class org.apache.hadoop.hbase.thrift.Constants
- THRIFT_KERBEROS_PRINCIPAL_KEY - Static variable in class org.apache.hadoop.hbase.thrift.Constants
- THRIFT_KEYTAB_FILE_KEY - Static variable in class org.apache.hadoop.hbase.thrift.Constants
- THRIFT_ONE_JMX_CONTEXT - Static variable in interface org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceFactory
- THRIFT_ONE_METRICS_CONTEXT - Static variable in interface org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceFactory
- THRIFT_QOP_KEY - Static variable in class org.apache.hadoop.hbase.thrift.Constants
-
Thrift quality of protection configuration key.
- THRIFT_QUEUE_SIZE - Static variable in class org.apache.hadoop.hbase.thrift.Constants
- THRIFT_QUEUE_SIZE_DEFAULT - Static variable in class org.apache.hadoop.hbase.thrift.Constants
- THRIFT_READONLY_ENABLED - Static variable in class org.apache.hadoop.hbase.thrift.Constants
- THRIFT_READONLY_ENABLED_DEFAULT - Static variable in class org.apache.hadoop.hbase.thrift.Constants
- THRIFT_SELECTOR_NUM - Static variable in class org.apache.hadoop.hbase.thrift.Constants
- THRIFT_SERVER_SOCKET_READ_TIMEOUT_DEFAULT - Static variable in class org.apache.hadoop.hbase.thrift.Constants
- THRIFT_SERVER_SOCKET_READ_TIMEOUT_KEY - Static variable in class org.apache.hadoop.hbase.thrift.Constants
-
Amount of time in milliseconds before a server thread will timeout waiting for client to send data on a connected socket.
- THRIFT_SPNEGO_KEYTAB_FILE_KEY - Static variable in class org.apache.hadoop.hbase.thrift.Constants
- THRIFT_SPNEGO_PRINCIPAL_KEY - Static variable in class org.apache.hadoop.hbase.thrift.Constants
- THRIFT_SSL_ENABLED_KEY - Static variable in class org.apache.hadoop.hbase.thrift.Constants
- THRIFT_SSL_EXCLUDE_CIPHER_SUITES_KEY - Static variable in class org.apache.hadoop.hbase.thrift.Constants
- THRIFT_SSL_EXCLUDE_PROTOCOLS_KEY - Static variable in class org.apache.hadoop.hbase.thrift.Constants
- THRIFT_SSL_INCLUDE_CIPHER_SUITES_KEY - Static variable in class org.apache.hadoop.hbase.thrift.Constants
- THRIFT_SSL_INCLUDE_PROTOCOLS_KEY - Static variable in class org.apache.hadoop.hbase.thrift.Constants
- THRIFT_SSL_KEYSTORE_KEYPASSWORD_KEY - Static variable in class org.apache.hadoop.hbase.thrift.Constants
- THRIFT_SSL_KEYSTORE_PASSWORD_KEY - Static variable in class org.apache.hadoop.hbase.thrift.Constants
- THRIFT_SSL_KEYSTORE_STORE_KEY - Static variable in class org.apache.hadoop.hbase.thrift.Constants
- THRIFT_SSL_KEYSTORE_TYPE_DEFAULT - Static variable in class org.apache.hadoop.hbase.thrift.Constants
- THRIFT_SSL_KEYSTORE_TYPE_KEY - Static variable in class org.apache.hadoop.hbase.thrift.Constants
- THRIFT_SUPPORT_PROXYUSER_KEY - Static variable in class org.apache.hadoop.hbase.thrift.Constants
- THRIFT_TWO_JMX_CONTEXT - Static variable in interface org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceFactory
- THRIFT_TWO_METRICS_CONTEXT - Static variable in interface org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceFactory
- org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler - Class in org.apache.hadoop.hbase.thrift
-
The HBaseServiceHandler is a glue object that connects Thrift RPC calls to the HBase client API primarily defined in the Admin and Table objects.
- ThriftHBaseServiceHandler(Configuration, UserProvider) - Constructor for class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
- org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler.IOErrorWithCause - Exception in org.apache.hadoop.hbase.thrift
- org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler.ResultScannerWrapper - Class in org.apache.hadoop.hbase.thrift
- org.apache.hadoop.hbase.thrift.ThriftHttpServlet - Class in org.apache.hadoop.hbase.thrift
-
Thrift Http Servlet is used for performing Kerberos authentication if security is enabled and also used for setting the user specified in "doAs" parameter.
- ThriftHttpServlet(TProcessor, TProtocolFactory, UserGroupInformation, UserGroupInformation, HBaseServiceHandler, boolean, boolean) - Constructor for class org.apache.hadoop.hbase.thrift.ThriftHttpServlet
- org.apache.hadoop.hbase.thrift.ThriftMetrics - Class in org.apache.hadoop.hbase.thrift
-
This class is for maintaining the various statistics of thrift server and publishing them through the metrics interfaces.
- ThriftMetrics(Configuration, ThriftMetrics.ThriftServerType) - Constructor for class org.apache.hadoop.hbase.thrift.ThriftMetrics
- org.apache.hadoop.hbase.thrift.ThriftMetrics.ThriftServerType - Enum Class in org.apache.hadoop.hbase.thrift
- org.apache.hadoop.hbase.thrift.ThriftServer - Class in org.apache.hadoop.hbase.thrift
-
ThriftServer- this class starts up a Thrift server which implements the Hbase API specified in the Hbase.thrift IDL file.
- ThriftServer(Configuration) - Constructor for class org.apache.hadoop.hbase.thrift.ThriftServer
- org.apache.hadoop.hbase.thrift.ThriftUtilities - Class in org.apache.hadoop.hbase.thrift
- THROTTLE - Enum constant in enum class org.apache.hadoop.hbase.quotas.QuotaType
- throttleCompaction(long) - Method in class org.apache.hadoop.hbase.regionserver.HStore
- org.apache.hadoop.hbase.io.hadoopbackport.ThrottledInputStream - Class in org.apache.hadoop.hbase.io.hadoopbackport
-
The ThrottleInputStream provides bandwidth throttling on a specified InputStream.
- ThrottledInputStream(InputStream) - Constructor for class org.apache.hadoop.hbase.io.hadoopbackport.ThrottledInputStream
- ThrottledInputStream(InputStream, long) - Constructor for class org.apache.hadoop.hbase.io.hadoopbackport.ThrottledInputStream
- throttleNamespace(String, ThrottleType, long, TimeUnit) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
-
Throttle the specified namespace.
- throttleNamespace(String, ThrottleType, long, TimeUnit, QuotaScope) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
-
Throttle the specified namespace.
- throttleRegionServer(String, ThrottleType, long, TimeUnit) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
-
Throttle the specified region server.
- org.apache.hadoop.hbase.quotas.ThrottleSettings - Class in org.apache.hadoop.hbase.quotas
- throttleTable(TableName, ThrottleType, long, TimeUnit) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
-
Throttle the specified table.
- throttleTable(TableName, ThrottleType, long, TimeUnit, QuotaScope) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
-
Throttle the specified table.
- org.apache.hadoop.hbase.quotas.ThrottleType - Enum Class in org.apache.hadoop.hbase.quotas
-
Describe the Throttle Type.
- throttleUser(String, String, ThrottleType, long, TimeUnit) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
-
Throttle the specified user on the specified namespace.
- throttleUser(String, String, ThrottleType, long, TimeUnit, QuotaScope) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
-
Throttle the specified user on the specified namespace.
- throttleUser(String, ThrottleType, long, TimeUnit) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
-
Throttle the specified user.
- throttleUser(String, ThrottleType, long, TimeUnit, QuotaScope) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
-
Throttle the specified user.
- throttleUser(String, TableName, ThrottleType, long, TimeUnit) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
-
Throttle the specified user on the specified table.
- throttleUser(String, TableName, ThrottleType, long, TimeUnit, QuotaScope) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
-
Throttle the specified user on the specified table.
- org.apache.hadoop.hbase.regionserver.throttle.ThroughputController - Interface in org.apache.hadoop.hbase.regionserver.throttle
-
A utility that constrains the total throughput of one or more simultaneous flows by sleeping when necessary.
- org.apache.hadoop.hbase.regionserver.throttle.ThroughputControlUtil - Class in org.apache.hadoop.hbase.regionserver.throttle
-
Helper methods for throttling
- throughputDesc(double) - Method in class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareThroughputController
- throughputDesc(long, long) - Method in class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareThroughputController
- ThrowableWithExtraContext(Throwable, long, String) - Constructor for class org.apache.hadoop.hbase.client.RetriesExhaustedException.ThrowableWithExtraContext
- thrown - Variable in class org.apache.hadoop.hbase.util.LoadTestTool
- throwNumReadRequestsExceeded(long) - Static method in exception org.apache.hadoop.hbase.quotas.RpcThrottlingException
- throwNumRequestsExceeded(long) - Static method in exception org.apache.hadoop.hbase.quotas.RpcThrottlingException
- throwNumWriteRequestsExceeded(long) - Static method in exception org.apache.hadoop.hbase.quotas.RpcThrottlingException
- throwReadCapacityUnitExceeded(long) - Static method in exception org.apache.hadoop.hbase.quotas.RpcThrottlingException
- throwReadSizeExceeded(long) - Static method in exception org.apache.hadoop.hbase.quotas.RpcThrottlingException
- throwRequestCapacityUnitExceeded(long) - Static method in exception org.apache.hadoop.hbase.quotas.RpcThrottlingException
- throwRequestSizeExceeded(long) - Static method in exception org.apache.hadoop.hbase.quotas.RpcThrottlingException
- throwWriteCapacityUnitExceeded(long) - Static method in exception org.apache.hadoop.hbase.quotas.RpcThrottlingException
- throwWriteSizeExceeded(long) - Static method in exception org.apache.hadoop.hbase.quotas.RpcThrottlingException
- ticket - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient.RpcChannelImplementation
- TIME_IN_QUEUE_KEY - Static variable in interface org.apache.hadoop.hbase.thrift.MetricsThriftServerSource
- TIME_INTERVAL - Enum constant in enum class org.apache.hadoop.hbase.util.PrettyPrinter.Unit
- TIME_LIMIT_REACHED - Enum constant in enum class org.apache.hadoop.hbase.regionserver.ScannerContext.NextState
- TIME_LIMIT_REACHED_MID_ROW - Enum constant in enum class org.apache.hadoop.hbase.regionserver.ScannerContext.NextState
-
Special case of time limit reached to indicate that the time limit was reached in the middle of a row and thus a partial results was formed
- TIME_TO_WAIT_AFTER_SHUTDOWN_MS - Static variable in class org.apache.hadoop.hbase.thrift.TBoundedThreadPoolServer
-
Time to wait after interrupting all worker threads.
- org.apache.hadoop.hbase.quotas.TimeBasedLimiter - Class in org.apache.hadoop.hbase.quotas
-
Simple time based limiter that checks the quota Throttle
- timeFromString(String) - Static method in exception org.apache.hadoop.hbase.quotas.RpcThrottlingException
- timeInQueue() - Method in class org.apache.hadoop.hbase.thrift.CallQueue.Call
- TIMELINE - Enum constant in enum class org.apache.hadoop.hbase.client.Consistency
-
Timeline consistent reads might return values that may not see the most recent updates.
- org.apache.hadoop.hbase.util.TimeMeasurable<T> - Interface in org.apache.hadoop.hbase.util
-
Methods that implement this interface can be measured elapsed time.
- timeOfOldestEdit() - Method in class org.apache.hadoop.hbase.regionserver.AbstractMemStore
-
Returns Oldest timestamp of all the Cells in the MemStore
- timeOfOldestEdit() - Method in class org.apache.hadoop.hbase.regionserver.HStore
- timeOfOldestEdit() - Method in interface org.apache.hadoop.hbase.regionserver.MemStore
-
Returns Oldest timestamp of all the Cells in the MemStore
- timeOfOldestEdit() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
When was the last edit done in the memstore
- timeout - Variable in class org.apache.hadoop.hbase.ipc.ServerCall
- timeout(int) - Method in class org.apache.hadoop.hbase.util.RegionMover.RegionMoverBuilder
-
Set the timeout for Load/Unload operation in seconds.This is a global timeout,threadpool for movers also have a separate time which is hbase.move.wait.max * number of regions to load/unload
- org.apache.hadoop.hbase.errorhandling.TimeoutException - Exception in org.apache.hadoop.hbase.errorhandling
-
Exception for timeout of a task.
- TimeoutException(String, long, long, long) - Constructor for exception org.apache.hadoop.hbase.errorhandling.TimeoutException
-
Exception indicating that an operation attempt has timed out
- org.apache.hadoop.hbase.errorhandling.TimeoutExceptionInjector - Class in org.apache.hadoop.hbase.errorhandling
-
Time a given process/operation and report a failure if the elapsed time exceeds the max allowed time.
- TimeoutExceptionInjector(ForeignExceptionListener, long) - Constructor for class org.apache.hadoop.hbase.errorhandling.TimeoutExceptionInjector
-
Create a generic timer for a task/process.
- org.apache.hadoop.hbase.exceptions.TimeoutIOException - Exception in org.apache.hadoop.hbase.exceptions
-
Exception thrown when a blocking operation times out.
- TimeoutIOException() - Constructor for exception org.apache.hadoop.hbase.exceptions.TimeoutIOException
- TimeoutIOException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.TimeoutIOException
- TimeoutIOException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.exceptions.TimeoutIOException
- TimeoutIOException(Throwable) - Constructor for exception org.apache.hadoop.hbase.exceptions.TimeoutIOException
- timer(String) - Method in interface org.apache.hadoop.hbase.metrics.MetricRegistry
-
Get or construct a
Timer
used to measure durations and report rates. - org.apache.hadoop.hbase.metrics.Timer - Interface in org.apache.hadoop.hbase.metrics
-
A metric which encompasses a
Histogram
andMeter
. - timeRange - Variable in class org.apache.hadoop.hbase.regionserver.StoreFileReader
- timeRange(TimeRange) - Method in interface org.apache.hadoop.hbase.client.AsyncTable.CheckAndMutateBuilder
-
Deprecated.Match a timerange.
- timeRange(TimeRange) - Method in interface org.apache.hadoop.hbase.client.AsyncTable.CheckAndMutateWithFilterBuilder
-
Deprecated.Match a timerange.
- timeRange(TimeRange) - Method in class org.apache.hadoop.hbase.client.CheckAndMutate.Builder
-
Specify a timerange
- timeRange(TimeRange) - Method in interface org.apache.hadoop.hbase.client.Table.CheckAndMutateBuilder
-
Deprecated.Specify a timerange
- timeRange(TimeRange) - Method in interface org.apache.hadoop.hbase.client.Table.CheckAndMutateWithFilterBuilder
-
Deprecated.Specify a timerange.
- org.apache.hadoop.hbase.io.TimeRange - Class in org.apache.hadoop.hbase.io
-
Represents an interval of version timestamps.
- TIMERANGE - Static variable in class org.apache.hadoop.hbase.util.ClassSize
-
Overhead for timerange
- TIMERANGE_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.HStoreFile
-
Key for Timerange information in metadata
- timeRangeTracker - Variable in class org.apache.hadoop.hbase.regionserver.Segment
- org.apache.hadoop.hbase.regionserver.TimeRangeTracker - Class in org.apache.hadoop.hbase.regionserver
-
Stores minimum and maximum timestamp values, it is [minimumTimestamp, maximumTimestamp] in interval notation.
- TimeRangeTracker() - Constructor for class org.apache.hadoop.hbase.regionserver.TimeRangeTracker
- org.apache.hadoop.hbase.regionserver.TimeRangeTracker.NonSyncTimeRangeTracker - Class in org.apache.hadoop.hbase.regionserver
- org.apache.hadoop.hbase.regionserver.TimeRangeTracker.SyncTimeRangeTracker - Class in org.apache.hadoop.hbase.regionserver
- org.apache.hadoop.hbase.regionserver.TimeRangeTracker.Type - Enum Class in org.apache.hadoop.hbase.regionserver
- timestamp - Variable in class org.apache.hadoop.hbase.ExtendedCellBuilderImpl
- TIMESTAMP_COLUMN - Static variable in class org.apache.hadoop.hbase.namequeues.WALEventTrackerTableAccessor
- TIMESTAMP_COMPARATOR - Static variable in class org.apache.hadoop.hbase.wal.AbstractFSWALProvider
- TIMESTAMP_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv
- TIMESTAMP_SIZE - Static variable in class org.apache.hadoop.hbase.KeyValue
-
Size of the timestamp field in bytes
- TIMESTAMP_TYPE_SIZE - Static variable in class org.apache.hadoop.hbase.KeyValue
- TIMESTAMPKEY_COLUMN_SPEC - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
- org.apache.hadoop.hbase.filter.TimestampsFilter - Class in org.apache.hadoop.hbase.filter
-
Filter that returns only cells whose timestamp (version) is in the specified list of timestamps (versions).
- TimestampsFilter(List<Long>) - Constructor for class org.apache.hadoop.hbase.filter.TimestampsFilter
-
Constructor for filter that retains only the specified timestamps in the list.
- TimestampsFilter(List<Long>, boolean) - Constructor for class org.apache.hadoop.hbase.filter.TimestampsFilter
-
Constructor for filter that retains only those cells whose timestamp (version) is in the specified list of timestamps.
- timeToPurgeDeletes - Variable in class org.apache.hadoop.hbase.regionserver.querymatcher.DropDeletesCompactionScanQueryMatcher
-
By default, when hbase.hstore.time.to.purge.deletes is 0ms, a delete marker is always removed during a major compaction.
- timeToString(TimeUnit) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettings
- org.apache.hadoop.hbase.io.hfile.TinyLfuBlockCache - Class in org.apache.hadoop.hbase.io.hfile
-
A block cache that is memory-aware using
HeapSize
, memory bounded using the W-TinyLFU eviction algorithm, and concurrent. - TinyLfuBlockCache(long, long, long, Executor) - Constructor for class org.apache.hadoop.hbase.io.hfile.TinyLfuBlockCache
-
Creates a block cache.
- TinyLfuBlockCache(long, long, Executor, Configuration) - Constructor for class org.apache.hadoop.hbase.io.hfile.TinyLfuBlockCache
-
Creates a block cache.
- TLS_CERT_RELOAD - Static variable in class org.apache.hadoop.hbase.io.crypto.tls.X509Util
- TLS_CIPHER_SUITES - Static variable in class org.apache.hadoop.hbase.io.crypto.tls.X509Util
- TLS_CONFIG_CLR - Static variable in class org.apache.hadoop.hbase.io.crypto.tls.X509Util
- TLS_CONFIG_KEYSTORE_LOCATION - Static variable in class org.apache.hadoop.hbase.io.crypto.tls.X509Util
- TLS_CONFIG_KEYSTORE_PASSWORD - Static variable in class org.apache.hadoop.hbase.io.crypto.tls.X509Util
- TLS_CONFIG_KEYSTORE_TYPE - Static variable in class org.apache.hadoop.hbase.io.crypto.tls.X509Util
- TLS_CONFIG_OCSP - Static variable in class org.apache.hadoop.hbase.io.crypto.tls.X509Util
- TLS_CONFIG_PROTOCOL - Static variable in class org.apache.hadoop.hbase.io.crypto.tls.X509Util
- TLS_CONFIG_REVERSE_DNS_LOOKUP_ENABLED - Static variable in class org.apache.hadoop.hbase.io.crypto.tls.X509Util
- TLS_CONFIG_TRUSTSTORE_LOCATION - Static variable in class org.apache.hadoop.hbase.io.crypto.tls.X509Util
- TLS_CONFIG_TRUSTSTORE_PASSWORD - Static variable in class org.apache.hadoop.hbase.io.crypto.tls.X509Util
- TLS_CONFIG_TRUSTSTORE_TYPE - Static variable in class org.apache.hadoop.hbase.io.crypto.tls.X509Util
- TLS_ENABLED_PROTOCOLS - Static variable in class org.apache.hadoop.hbase.io.crypto.tls.X509Util
- TLS_USE_OPENSSL - Static variable in class org.apache.hadoop.hbase.io.crypto.tls.X509Util
- tmpPair - Variable in class org.apache.hadoop.hbase.io.encoding.RowIndexSeekerV1
- toAppend(ClientProtos.MutationProto, CellScanner) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Convert a protocol buffer Mutate to an Append
- toArray() - Method in class org.apache.hadoop.hbase.ipc.AdaptiveLifoCoDelCallQueue
- toArray() - Method in class org.apache.hadoop.hbase.regionserver.CellSet
- toArray() - Method in class org.apache.hadoop.hbase.thrift.CallQueue
- toArray() - Method in class org.apache.hadoop.hbase.util.SortedList
- toArray(List<byte[]>) - Static method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
-
Convert a list of byte arrays into an array of byte arrays
- toArray(List<byte[]>) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Convert a list of byte[] to an array
- toArray(T[]) - Method in class org.apache.hadoop.hbase.ipc.AdaptiveLifoCoDelCallQueue
- toArray(T[]) - Method in class org.apache.hadoop.hbase.regionserver.CellSet
- toArray(T[]) - Method in class org.apache.hadoop.hbase.thrift.CallQueue
- toArray(T[]) - Method in class org.apache.hadoop.hbase.util.SortedList
- toAssignRegionsRequest(List<String>, boolean, boolean) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
- toAsyncConnection() - Method in interface org.apache.hadoop.hbase.client.Connection
-
Convert this connection to an
AsyncConnection
. - toAsyncConnection() - Method in class org.apache.hadoop.hbase.client.SharedConnection
- toAuthorizations(byte[]) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Convert a protocol buffer Authorizations bytes to a client Authorizations
- toAuthorizations(Authorizations) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Create a protocol buffer Authorizations based on a client Authorizations.
- toAuthorizations(ClientProtos.Authorizations) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Convert a protocol buffer Authorizations to a client Authorizations
- toBalancerDecisionRequest(int) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
- toBalancerDecisionResponse(HBaseProtos.LogEntry) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
- toBalanceRequest(BalanceRequest) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
- toBalanceRequest(MasterProtos.BalanceRequest) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
- toBalanceRequest(RSGroupAdminProtos.BalanceRSGroupRequest) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
- toBalanceResponse(BalanceResponse) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
- toBalanceResponse(MasterProtos.BalanceResponse) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
- toBalanceResponse(RSGroupAdminProtos.BalanceRSGroupResponse) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
- toBalancerRejectionRequest(int) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
- toBalancerRejectionResponse(HBaseProtos.LogEntry) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
- toBigDecimal(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Converts a byte array to a BigDecimal
- toBigDecimal(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Converts a byte array to a BigDecimal value
- toBigDecimal(ByteBuffer, int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Reads a BigDecimal value at the given buffer's offset.
- toBinaryByteArrays(String[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Create an array of byte[] given an array of String.
- toBinaryFromHex(byte) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Takes a ASCII digit in the range A-F0-9 and returns the corresponding integer/ordinal value.
- toBoolean(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Reverses
Bytes.toBytes(boolean)
- toBulkLoadDescriptor(TableName, ByteString, Map<byte[], List<Path>>, Map<String, Long>, long) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Generates a marker for the WAL so that we propagate the notion of a bulk region load throughout the WAL.
- toBulkLoadDescriptor(TableName, ByteString, Map<byte[], List<Path>>, Map<String, Long>, long, List<String>, boolean) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
- toByte() - Method in enum class org.apache.hadoop.hbase.client.IsolationLevel
- toByte(Object, long) - Static method in class org.apache.hadoop.hbase.util.UnsafeAccess
-
Returns the byte at the given offset of the object
- toByte(ByteBuffer, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
- toByte(ByteBuffer, int) - Static method in class org.apache.hadoop.hbase.util.UnsafeAccess
-
Returns the byte at the given offset
- toByteArray() - Method in class org.apache.hadoop.hbase.backup.BackupInfo
- toByteArray() - Method in class org.apache.hadoop.hbase.ClusterId
-
Returns The clusterid serialized using pb w/ pb magic prefix
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.BigDecimalComparator
-
Returns The comparator serialized using pb
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.BinaryComparator
-
Returns The comparator serialized using pb
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.BinaryComponentComparator
-
Returns The comparator serialized using pb
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.BinaryPrefixComparator
-
Returns The comparator serialized using pb
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.BitComparator
-
Returns The comparator serialized using pb
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.ByteArrayComparable
-
Returns The comparator serialized using pb
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
-
Returns The filter serialized using pb
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
-
Returns The filter serialized using pb
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.ColumnPrefixFilter
-
Returns The filter serialized using pb
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
-
Returns The filter serialized using pb
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.ColumnValueFilter
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
-
Returns The filter serialized using pb
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.FamilyFilter
-
Returns The filter serialized using pb
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.Filter
-
TODO: JAVADOC Concrete implementers can signal a failure condition in their code by throwing an
IOException
. - toByteArray() - Method in class org.apache.hadoop.hbase.filter.FilterBase
-
Return length 0 byte array for Filters that don't require special serialization
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.FilterList
-
Returns The filter serialized using pb
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.FilterWrapper
-
Returns The filter serialized using pb
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
-
Returns The filter serialized using pb
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.FuzzyRowFilter
-
Returns The filter serialized using pb
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.InclusiveStopFilter
-
Returns The filter serialized using pb
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter
-
Returns The filter serialized using pb
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.LongComparator
-
Returns The comparator serialized using pb
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
-
Returns The filter serialized using pb
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter
-
Returns The filter serialized using pb
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.NullComparator
-
Returns The comparator serialized using pb
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.PageFilter
-
Returns The filter serialized using pb
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.PrefixFilter
-
Returns The filter serialized using pb
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.QualifierFilter
-
Returns The filter serialized using pb
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.RandomRowFilter
-
Returns The filter serialized using pb
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.RegexStringComparator
-
Returns The comparator serialized using pb
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.RowFilter
-
Returns The filter serialized using pb
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter
-
Returns The filter serialized using pb
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
Returns The filter serialized using pb
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.SkipFilter
-
Returns The filter serialized using pb
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.SubstringComparator
-
Returns The comparator serialized using pb
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.TimestampsFilter
-
Returns The filter serialized using pb
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.ValueFilter
-
Returns The filter serialized using pb
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
-
Returns The filter serialized using pb
- toByteArray() - Method in class org.apache.hadoop.hbase.io.ByteArrayOutputStream
-
Copies the content of this Stream into a new byte array.
- toByteArray() - Method in class org.apache.hadoop.hbase.io.Reference
-
Use this when writing to a stream and you want to use the pb mergeDelimitedFrom (w/o the delimiter, pb reads to EOF which may not be what you want).
- toByteArray() - Method in class org.apache.hadoop.hbase.SplitLogTask
-
Deprecated.
- toByteArray(boolean) - Method in class org.apache.hadoop.hbase.master.BooleanStateStore
- toByteArray(int, int) - Method in class org.apache.hadoop.hbase.io.ByteBufferListOutputStream
- toByteArray(int, int) - Method in class org.apache.hadoop.hbase.io.ByteBufferOutputStream
- toByteArray(ColumnFamilyDescriptor) - Static method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
Serialize the table descriptor to a byte array.
- toByteArray(RegionInfo) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Returns This instance serialized as protobuf w/ a magic pb prefix.
- toByteArray(TableDescriptor) - Static method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
Returns This instance serialized with pb with pb magic prefix
- toByteArray(TimeRangeTracker) - Static method in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker
-
This method used to serialize TimeRangeTracker (TRT) by protobuf while this breaks the forward compatibility on HFile.(See HBASE-21008) In previous hbase version ( < 2.0.0 ) we use DataOutput to serialize TRT, these old versions don't have capability to deserialize TRT which is serialized by protobuf.
- toByteArray(ReplicationPeerConfig) - Static method in class org.apache.hadoop.hbase.client.replication.ReplicationPeerConfigUtil
-
Returns Serialized protobuf of
peerConfig
with pb magic prefix prepended suitable for use as content of a this.peersZNode; i.e. - toByteArray(SyncReplicationState) - Static method in enum class org.apache.hadoop.hbase.replication.SyncReplicationState
- toByteArray(SyncReplicationState, SyncReplicationState) - Static method in enum class org.apache.hadoop.hbase.replication.SyncReplicationState
- toByteArray(ReplicationProtos.ReplicationState.State) - Static method in class org.apache.hadoop.hbase.replication.ZKReplicationStorageBase
-
Serialized protobuf of
state
with pb magic prefix prepended suitable for use as content of a peer-state znode under a peer cluster id as in /hbase/replication/peers/PEER_ID/peer-state. - toByteArrayComparable(byte[]) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
- toByteArrays(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Create a byte[][] where first and only entry is
column
- toByteArrays(String) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Create a byte[][] where first and only entry is
column
- toByteArrays(String[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Create an array of byte[] given an array of String.
- toByteBuff(ByteBuff) - Method in class org.apache.hadoop.hbase.io.ByteArrayOutputStream
- toByteBufferAndRewind(Iterable<? extends KeyValue>, boolean) - Static method in class org.apache.hadoop.hbase.KeyValueTestUtil
- toBytes() - Method in enum class org.apache.hadoop.hbase.client.IsolationLevel
- toBytes() - Method in class org.apache.hadoop.hbase.nio.ByteBuff
-
Copy the content from this ByteBuff to a byte[].
- toBytes() - Method in class org.apache.hadoop.hbase.TableName
-
Returns A pointer to TableName as String bytes.
- toBytes(boolean) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Convert a boolean to a byte array.
- toBytes(double) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Serialize a double as the IEEE 754 double format output.
- toBytes(float) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Return the float represented as byte[]
- toBytes(int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Convert an int value to a byte array.
- toBytes(int, int) - Method in class org.apache.hadoop.hbase.nio.ByteBuff
-
Copy the content from this ByteBuff to a byte[] based on the given offset and length.
- toBytes(int, int) - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
Copy the content from this MBB to a byte[] based on the given offset and length the position from where the copy should start the length upto which the copy has to be done
- toBytes(int, int) - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
- toBytes(long) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Convert a long value to a byte array using big-endian.
- toBytes(short) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Convert a short value to a byte array of
Bytes.SIZEOF_SHORT
bytes long. - toBytes(String) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Converts a string to a UTF-8 byte array.
- toBytes(BigDecimal) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Convert a BigDecimal value to a byte array
- toBytes(ByteBuffer) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Returns a new byte array, copied from the given
buf
, from the index 0 (inclusive) to the limit (exclusive), regardless of the current position. - toBytes(ByteBuffer, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Copy the bytes from position to limit into a new byte[] of the exact length and sets the position and limit back to their original values (though not thread safe).
- toBytes(ByteBuffer, int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Copy the given number of bytes from specified offset into a new byte[]
- toBytes(ByteString) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
- toBytesBinary(String) - Static method in class org.apache.hadoop.hbase.util.Bytes
- toCacheEvictionStats(CacheEvictionStats) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
- toCacheEvictionStats(HBaseProtos.CacheEvictionStats) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
- toCell(ExtendedCellBuilder, CellProtos.Cell, boolean) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
- toCell(ExtendedCell, boolean) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
- toCellVisibility(byte[]) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Convert a protocol buffer CellVisibility bytes to a client CellVisibility
- toCellVisibility(CellVisibility) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Create a protocol buffer CellVisibility based on a client CellVisibility.
- toCellVisibility(ClientProtos.CellVisibility) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Convert a protocol buffer CellVisibility to a client CellVisibility
- toCheckAndMutate(ClientProtos.Condition, List<Mutation>) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
- toCheckAndMutate(ClientProtos.Condition, ClientProtos.MutationProto, CellScanner) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
- toClearSlowLogPayload(AdminProtos.ClearSlowLogResponses) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Convert
AdminProtos.ClearSlowLogResponses
to boolean - toClusterMetrics(ClusterStatusProtos.ClusterStatus) - Static method in class org.apache.hadoop.hbase.ClusterMetricsBuilder
- toClusterStatus(ClusterMetrics) - Static method in class org.apache.hadoop.hbase.ClusterMetricsBuilder
- toColumnFamilyDescriptor(HBaseProtos.ColumnFamilySchema) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Converts a ColumnFamilySchema to ColumnFamilyDescriptor
- toColumnFamilySchema(ColumnFamilyDescriptor) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Converts an ColumnFamilyDescriptor to ColumnFamilySchema
- toCompactedStoreFiles(byte[]) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
- toCompactionDescriptor(RegionInfo, byte[], byte[], List<Path>, List<Path>, Path) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
- toCompactionDescriptor(RegionInfo, byte[], List<Path>, List<Path>, Path) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
- toCompactionEventTrackerBytes(Set<String>) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
- toComparator(ByteArrayComparable) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Convert a ByteArrayComparable to a protocol buffer Comparator
- toComparator(ComparatorProtos.Comparator) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Convert a protocol buffer Comparator to a ByteArrayComparable
- toCondition(byte[], byte[], byte[], CompareOperator, byte[], Filter, TimeRange) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
- toCondition(byte[], byte[], byte[], CompareOperator, byte[], TimeRange) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
- toCondition(byte[], Filter, TimeRange) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
- toConnection() - Method in interface org.apache.hadoop.hbase.client.AsyncConnection
-
Convert this connection to a
Connection
. - toConnection() - Method in class org.apache.hadoop.hbase.client.AsyncConnectionImpl
- toConnection() - Method in class org.apache.hadoop.hbase.client.SharedAsyncConnection
- toConsistency(Consistency) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
- toConsistency(ClientProtos.Consistency) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
- toCoprocessor(Collection<String>) - Static method in class org.apache.hadoop.hbase.ServerMetricsBuilder
- toCursor(Cell) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
- toCursor(Cursor) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
- toCursor(ClientProtos.Cursor) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
- toDelete(ClientProtos.MutationProto) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Convert a protocol buffer Mutate to a Delete
- toDelete(ClientProtos.MutationProto, CellScanner) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Convert a protocol buffer Mutate to a Delete
- toDeleteType(KeyValue.Type) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Convert a delete KeyValue type to protocol buffer DeleteType.
- toDelimitedByteArray(RegionInfo) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Use this instead of
RegionInfo.toByteArray(RegionInfo)
when writing to a stream and you want to use the pb mergeDelimitedFrom (w/o the delimiter, pb reads to EOF which may not be what you want). - toDelimitedByteArray(RegionInfo...) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Serializes given RegionInfo's as a byte array.
- toDelimitedByteArray(Message) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
- toDescriptiveString() - Method in class org.apache.hadoop.hbase.master.RegionState
-
A slower (but more easy-to-read) stringification
- toDouble(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Return double made from passed bytes.
- toDouble(byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Return double made from passed bytes.
- toDouble(ByteBuffer, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Reads a double value at the given buffer's offset.
- toDurability(Durability) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Convert a client Durability into a protbuf Durability
- toDurability(ClientProtos.MutationProto.Durability) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Convert a protobuf Durability into a client Durability
- toException(HBaseProtos.NameBytesPair) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Convert a stringified protocol buffer exception Parameter to a Java Exception
- toFilter(Filter) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Convert a client Filter to a protocol buffer Filter
- toFilter(FilterProtos.Filter) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Convert a protocol buffer Filter to a client Filter
- toFloat(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Put a float value out to the specified byte array position.
- toFloat(byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Put a float value out to the specified byte array position.
- toFlushDescriptor(WALProtos.FlushDescriptor.FlushAction, RegionInfo, long, Map<byte[], List<Path>>) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
- toGet(Get) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Create a protocol buffer Get based on a client Get.
- toGet(ClientProtos.Get) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Convert a protocol buffer Get to a client Get
- toGroupEntry(String) - Static method in class org.apache.hadoop.hbase.AuthUtil
-
Deprecated.Returns the group entry with the group prefix for a group principal.
- toGroupInfo(RSGroupProtos.RSGroupInfo) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
- toHex(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Convert a byte array into a hex string
- toHex(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Convert a byte range into a hex string
- toIncrement(ClientProtos.MutationProto, CellScanner) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Convert a protocol buffer Mutate to an Increment
- toInt(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Converts a byte array to an int value
- toInt(byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Converts a byte array to an int value
- toInt(byte[], int) - Static method in class org.apache.hadoop.hbase.util.UnsafeAccess
-
Converts a byte array to an int value considering it was written in big-endian format.
- toInt(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Converts a byte array to an int value
- toInt(Object, long) - Static method in class org.apache.hadoop.hbase.util.UnsafeAccess
-
Reads a int value at the given Object's offset considering it was written in big-endian format.
- toInt(ByteBuffer) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Reads an int value at the given buffer's current position.
- toInt(ByteBuffer, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Reads an int value at the given buffer's offset.
- toInt(ByteBuffer, int) - Static method in class org.apache.hadoop.hbase.util.UnsafeAccess
-
Reads an int value at the given buffer's offset considering it was written in big-endian format.
- toIOException(ServiceException) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Unwraps an exception from a protobuf service into the underlying (expected) IOException.
- toJSON() - Method in class org.apache.hadoop.hbase.client.ImmutableScan
- toJSON() - Method in class org.apache.hadoop.hbase.client.Operation
-
Produces a JSON object sufficient for description of a query in a debugging or logging context.
- toJSON(int) - Method in class org.apache.hadoop.hbase.client.ImmutableScan
- toJSON(int) - Method in class org.apache.hadoop.hbase.client.Operation
-
Produces a JSON object for fingerprint and details exposure in a parseable format.
- toJSON(String, NavigableSet<CachedBlock>) - Static method in class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil
-
Returns A JSON String of
filename
and counts ofblocks
- toJSON(BlockCache) - Static method in class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil
-
Returns JSON string of
bc
content. - toJSON(BlockCacheUtil.CachedBlocksByFile) - Static method in class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil
-
Returns JSON string of
cbsf
aggregated - toJsonPrettyPrint() - Method in class org.apache.hadoop.hbase.client.BalancerDecision
- toJsonPrettyPrint() - Method in class org.apache.hadoop.hbase.client.BalancerRejection
- toJsonPrettyPrint() - Method in class org.apache.hadoop.hbase.client.LogEntry
-
Based on response sent by server, provide pretty printed Json representation in string
- toJsonPrettyPrint() - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord
- toLockJson(List<LockServiceProtos.LockedResource>) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
- toLong(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Converts a byte array to a long value.
- toLong(byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Converts a byte array to a long value.
- toLong(byte[], int) - Static method in class org.apache.hadoop.hbase.util.UnsafeAccess
-
Converts a byte array to a long value considering it was written in big-endian format.
- toLong(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Converts a byte array to a long value.
- toLong(Object, long) - Static method in class org.apache.hadoop.hbase.util.UnsafeAccess
-
Reads a long value at the given Object's offset considering it was written in big-endian format.
- toLong(ByteBuffer, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Reads a long value at the given buffer's offset.
- toLong(ByteBuffer, int) - Static method in class org.apache.hadoop.hbase.util.UnsafeAccess
-
Reads a long value at the given buffer's offset considering it was written in big-endian format.
- toLowerCase(HttpServletRequest) - Static method in class org.apache.hadoop.hbase.http.ProxyUserAuthenticationFilter
- toMap() - Method in class org.apache.hadoop.hbase.client.ImmutableScan
- toMap() - Method in class org.apache.hadoop.hbase.client.Operation
-
Produces a Map containing a full summary of a query.
- toMap(int) - Method in class org.apache.hadoop.hbase.client.Get
-
Compile the details beyond the scope of getFingerprint (row, columns, timestamps, etc.) into a Map along with the fingerprinted information.
- toMap(int) - Method in class org.apache.hadoop.hbase.client.ImmutableScan
- toMap(int) - Method in class org.apache.hadoop.hbase.client.Mutation
-
Compile the details beyond the scope of getFingerprint (row, columns, timestamps, etc.) into a Map along with the fingerprinted information.
- toMap(int) - Method in class org.apache.hadoop.hbase.client.Operation
-
Produces a Map containing a summary of the details of a query beyond the scope of the fingerprint (i.e.
- toMap(int) - Method in class org.apache.hadoop.hbase.client.Scan
-
Compile the details beyond the scope of getFingerprint (row, columns, timestamps, etc.) into a Map along with the fingerprinted information.
- toMutation(ClientProtos.MutationProto) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Convert a MutateRequest to Mutation
- toMutation(ClientProtos.MutationProto.MutationType, Mutation) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
- toMutation(ClientProtos.MutationProto.MutationType, Mutation, long) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Create a protocol buffer Mutate based on a client Mutation
- toMutation(ClientProtos.MutationProto.MutationType, Mutation, ClientProtos.MutationProto.Builder) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
- toMutation(ClientProtos.MutationProto.MutationType, Mutation, ClientProtos.MutationProto.Builder, long) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
- toMutationNoData(ClientProtos.MutationProto.MutationType, Mutation) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Create a protocol buffer MutationProto based on a client Mutation.
- toMutationNoData(ClientProtos.MutationProto.MutationType, Mutation, ClientProtos.MutationProto.Builder) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Create a protocol buffer MutationProto based on a client Mutation.
- toMutationNoData(ClientProtos.MutationProto.MutationType, Mutation, ClientProtos.MutationProto.Builder, long) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
- toNamespaceDescriptor(HBaseProtos.NamespaceDescriptor) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
- toNamespaceDescriptorList(MasterProtos.ListNamespaceDescriptorsResponse) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Get a list of NamespaceDescriptor from ListNamespaceDescriptorsResponse protobuf
- toNettyClientAuth() - Method in enum class org.apache.hadoop.hbase.io.crypto.tls.X509Util.ClientAuth
- toNewKeyCell(ExtendedCell) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
-
Copies the key to a new KeyValue
- tooBusyException() - Method in interface org.apache.hadoop.hbase.metrics.ExceptionTrackingSource
- tooBusyException() - Method in class org.apache.hadoop.hbase.metrics.ExceptionTrackingSourceImpl
- TOOLS - Static variable in class org.apache.hadoop.hbase.HBaseInterfaceAudience
-
Denotes classes used as tools (Used from cmd line).
- toOption(ClusterMetrics.Option) - Static method in class org.apache.hadoop.hbase.ClusterMetricsBuilder
-
Convert ClusterMetrics.Option to ClusterStatusProtos.Option
- toOption(ClusterStatusProtos.Option) - Static method in class org.apache.hadoop.hbase.ClusterMetricsBuilder
-
Convert ClusterStatusProtos.Option to ClusterMetrics.Option
- toOptionalTimestamp(MasterProtos.MajorCompactionTimestampResponse) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
- toOptions(EnumSet<ClusterMetrics.Option>) - Static method in class org.apache.hadoop.hbase.ClusterMetricsBuilder
-
Convert an enum set of ClusterMetrics.Option to a list of ClusterStatusProtos.Option
- toOptions(List<ClusterStatusProtos.Option>) - Static method in class org.apache.hadoop.hbase.ClusterMetricsBuilder
-
Convert a list of ClusterStatusProtos.Option to an enum set of ClusterMetrics.Option
- toProcedureJson(List<ProcedureProtos.Procedure>) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Helper to convert the protobuf Procedure to JSON String
- toProto() - Method in class org.apache.hadoop.hbase.backup.BackupTableInfo
- toProto(SpaceQuotaSnapshot.SpaceQuotaStatus) - Static method in class org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot.SpaceQuotaStatus
- toProtoGroupInfo(RSGroupInfo) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
- toProtoNamespaceDescriptor(NamespaceDescriptor) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
- toProtoQuotaScope(QuotaScope) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Convert a client QuotaScope to a protocol buffer QuotaScope
- toProtoQuotaScope(QuotaType) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Convert a client QuotaType to a protocol buffer QuotaType
- toProtoReplicationPeerDescription(ReplicationPeerDescription) - Static method in class org.apache.hadoop.hbase.client.replication.ReplicationPeerConfigUtil
- toProtosBackupInfo() - Method in class org.apache.hadoop.hbase.backup.BackupInfo
- toProtoSnapshot(SpaceQuotaSnapshot) - Static method in class org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot
- toProtoSpaceQuota(long, SpaceViolationPolicy) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Builds a protocol buffer SpaceQuota.
- toProtoTableName(TableName) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
- toProtoTableNameList(List<TableName>) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
- toProtoThrottleType(ThrottleType) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Convert a client ThrottleType to a protocol buffer ThrottleType
- toProtoTimeUnit(TimeUnit) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Convert a client TimeUnit to a protocol buffer TimeUnit
- toProtoViolationPolicy(SpaceViolationPolicy) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Converts a client SpaceViolationPolicy to a protocol buffer SpaceViolationPolicy.
- org.apache.hadoop.hbase.hbtop.screen.top.TopScreenModel - Class in org.apache.hadoop.hbase.hbtop.screen.top
-
The data and business logic for the top screen.
- TopScreenModel(Admin, Mode, List<Field>, Field, Boolean, List<RecordFilter>) - Constructor for class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenModel
- org.apache.hadoop.hbase.hbtop.screen.top.TopScreenPresenter - Class in org.apache.hadoop.hbase.hbtop.screen.top
-
The presentation logic for the top screen.
- TopScreenPresenter(TopScreenView, long, TopScreenModel, List<Field>, long) - Constructor for class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenPresenter
- org.apache.hadoop.hbase.hbtop.screen.top.TopScreenView - Class in org.apache.hadoop.hbase.hbtop.screen.top
-
The screen that provides a dynamic real-time view for the HBase metrics.
- TopScreenView(Screen, Terminal, long, Admin, Mode, List<Field>, Field, Boolean, List<RecordFilter>, long) - Constructor for class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenView
- toPut(ClientProtos.MutationProto) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Convert a protocol buffer Mutate to a Put.
- toPut(ClientProtos.MutationProto, CellScanner) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Convert a protocol buffer Mutate to a Put.
- toQuotas() - Method in class org.apache.hadoop.hbase.quotas.GlobalQuotaSettingsImpl
-
Constructs a new
QuotaProtos.Quotas
message fromthis
. - toQuotaScope(QuotaProtos.QuotaScope) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Convert a protocol buffer QuotaScope to a client QuotaScope
- toQuotaScope(QuotaProtos.QuotaType) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Convert a protocol buffer QuotaType to a client QuotaType
- toReadType(Scan.ReadType) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
- toReadType(ClientProtos.Scan.ReadType) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
- toRegionEventDescriptor(WALProtos.RegionEventDescriptor.EventType, byte[], byte[], byte[], long, ServerName, Map<byte[], List<Path>>) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
- toRegionEventDescriptor(WALProtos.RegionEventDescriptor.EventType, RegionInfo, long, ServerName, Map<byte[], List<Path>>) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
- toRegionInfo(RegionInfo) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Convert a RegionInfo to a Proto RegionInfo
- toRegionInfo(HBaseProtos.RegionInfo) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Convert HBaseProto.RegionInfo to a RegionInfo
- toRegionLoad(RegionMetrics) - Static method in class org.apache.hadoop.hbase.RegionMetricsBuilder
- toRegionLocation(HRegionLocation) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
- toRegionLocation(HBaseProtos.RegionLocation) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
- toRegionMetrics(AdminProtos.GetRegionLoadResponse) - Static method in class org.apache.hadoop.hbase.RegionMetricsBuilder
- toRegionMetrics(ClusterStatusProtos.RegionLoad) - Static method in class org.apache.hadoop.hbase.RegionMetricsBuilder
- toReplicationLoadSink(ReplicationLoadSink) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
- toReplicationLoadSink(ClusterStatusProtos.ReplicationLoadSink) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
- toReplicationLoadSource(ReplicationLoadSource) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
- toReplicationLoadSource(ClusterStatusProtos.ReplicationLoadSource) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
- toReplicationPeerDescription(ReplicationProtos.ReplicationPeerDescription) - Static method in class org.apache.hadoop.hbase.client.replication.ReplicationPeerConfigUtil
- toResult(boolean, boolean) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Convert a client Result to a protocol buffer Result
- toResult(Result) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Convert a client Result to a protocol buffer Result
- toResult(Result, boolean) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Convert a client Result to a protocol buffer Result
- toResult(ClientProtos.Result) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Convert a protocol buffer Result to a client Result
- toResult(ClientProtos.Result, boolean) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Convert a protocol buffer Result to a client Result
- toResult(ClientProtos.Result, CellScanner) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Convert a protocol buffer Result to a client Result
- toResultNoData(Result) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Convert a client Result to a protocol buffer Result.
- toRow(byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncTable.CoprocessorServiceBuilder
-
Specify a stop row
- toRow(byte[], boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncTable.CoprocessorServiceBuilder
-
Specify a stop row
- toScan(Scan) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Convert a client Scan to a protocol buffer Scan
- toScan(ClientProtos.Scan) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Convert a protocol buffer Scan to a client Scan
- toScanMetrics(byte[]) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
- toScanMetrics(ScanMetrics, boolean) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
- toScheduleServerCrashProcedureRequest(List<ServerName>) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
- toSecurityCapabilityList(List<MasterProtos.SecurityCapabilitiesResponse.Capability>) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Convert SecurityCapabilitiesResponse.Capability to SecurityCapability
- toServerLoad(ServerMetrics) - Static method in class org.apache.hadoop.hbase.ServerMetricsBuilder
- toServerMetrics(ServerName, int, String, ClusterStatusProtos.ServerLoad) - Static method in class org.apache.hadoop.hbase.ServerMetricsBuilder
- toServerMetrics(ServerName, ClusterStatusProtos.ServerLoad) - Static method in class org.apache.hadoop.hbase.ServerMetricsBuilder
- toServerMetrics(ClusterStatusProtos.LiveServerInfo) - Static method in class org.apache.hadoop.hbase.ServerMetricsBuilder
- toServerName(byte[]) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Get a ServerName from the passed in data bytes.
- toServerName(ServerName) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Convert a ServerName to a protocol buffer ServerName
- toServerName(HBaseProtos.ServerName) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Convert a protocol buffer ServerName to a ServerName
- toServerNameList(List<HBaseProtos.ServerName>) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Convert a list of protocol buffer ServerName to a list of ServerName
- toServerTask(ServerTask) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
- toShort(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Converts a byte array to a short value
- toShort(byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Converts a byte array to a short value
- toShort(byte[], int) - Static method in class org.apache.hadoop.hbase.util.UnsafeAccess
-
Converts a byte array to a short value considering it was written in big-endian format.
- toShort(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Converts a byte array to a short value
- toShort(byte, byte) - Static method in class org.apache.hadoop.hbase.io.util.StreamUtils
- toShort(Object, long) - Static method in class org.apache.hadoop.hbase.util.UnsafeAccess
-
Reads a short value at the given Object's offset considering it was written in big-endian format.
- toShort(ByteBuffer, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Reads a short value at the given buffer's offset.
- toShort(ByteBuffer, int) - Static method in class org.apache.hadoop.hbase.util.UnsafeAccess
-
Reads a short value at the given buffer's offset considering it was written in big-endian format.
- toShortString() - Method in interface org.apache.hadoop.hbase.ipc.RpcCall
-
Returns A short string format of this call without possibly lengthy params
- toShortString() - Method in class org.apache.hadoop.hbase.ipc.ServerCall
- toShortString() - Method in class org.apache.hadoop.hbase.ServerName
-
Return a SHORT version of
ServerName.toString()
, one that has the host only, minus the domain, and the port only -- no start code; the String is for us internally mostly tying threads to their server. - toSlowLogPayloads(HBaseProtos.LogEntry) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Convert AdminProtos#SlowLogResponses to list of
OnlineLogRecord
- toSnapshotDescriptionList(MasterProtos.GetCompletedSnapshotsResponse, Pattern) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
- toSocketAddress(Address) - Static method in class org.apache.hadoop.hbase.net.Address
- toSocketAddress(Address[]) - Static method in class org.apache.hadoop.hbase.net.Address
- toSpaceQuotaSnapshot(QuotaProtos.SpaceQuotaSnapshot) - Static method in class org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot
- toStatus(QuotaProtos.SpaceQuotaStatus) - Static method in class org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot.SpaceQuotaStatus
- toStoreFileInfo(Collection<HStoreFile>) - Static method in class org.apache.hadoop.hbase.regionserver.StoreUtils
- toString() - Method in class org.apache.hadoop.hbase.ArrayBackedTag
- toString() - Method in class org.apache.hadoop.hbase.backup.BackupInfo
- toString() - Method in class org.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValue
- toString() - Method in class org.apache.hadoop.hbase.ByteBufferKeyValue
- toString() - Method in class org.apache.hadoop.hbase.ByteBufferTag
- toString() - Method in class org.apache.hadoop.hbase.CacheEvictionStats
- toString() - Method in class org.apache.hadoop.hbase.client.BalancerDecision
- toString() - Method in class org.apache.hadoop.hbase.client.BalancerRejection
- toString() - Method in class org.apache.hadoop.hbase.client.ImmutableScan
- toString() - Method in class org.apache.hadoop.hbase.client.Increment
- toString() - Method in class org.apache.hadoop.hbase.client.locking.EntityLock
- toString() - Method in class org.apache.hadoop.hbase.client.LogQueryFilter
-
Deprecated.
- toString() - Method in class org.apache.hadoop.hbase.client.MetricsConnection.CallTracker
- toString() - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord
- toString() - Method in class org.apache.hadoop.hbase.client.Operation
-
Produces a string representation of this Operation.
- toString() - Method in class org.apache.hadoop.hbase.client.RegionCoprocessorServiceExec
- toString() - Method in class org.apache.hadoop.hbase.client.RegionStatesCount
- toString() - Method in class org.apache.hadoop.hbase.client.replication.TableCFs
- toString() - Method in class org.apache.hadoop.hbase.client.Result
- toString() - Method in class org.apache.hadoop.hbase.client.RetriesExhaustedException.ThrowableWithExtraContext
- toString() - Method in class org.apache.hadoop.hbase.client.SlowLogParams
- toString() - Method in class org.apache.hadoop.hbase.client.SnapshotDescription
- toString() - Method in class org.apache.hadoop.hbase.client.TableState
- toString() - Method in class org.apache.hadoop.hbase.ClusterId
- toString() - Method in class org.apache.hadoop.hbase.CompoundConfiguration
- toString() - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
- toString() - Method in exception org.apache.hadoop.hbase.errorhandling.ForeignException
- toString() - Method in class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
- toString() - Method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
- toString() - Method in class org.apache.hadoop.hbase.filter.ColumnPrefixFilter
- toString() - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
- toString() - Method in class org.apache.hadoop.hbase.filter.ColumnValueFilter
- toString() - Method in class org.apache.hadoop.hbase.filter.CompareFilter
- toString() - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
- toString() - Method in class org.apache.hadoop.hbase.filter.FilterBase
-
Return filter's info for debugging and logging purpose.
- toString() - Method in class org.apache.hadoop.hbase.filter.FilterList
- toString() - Method in class org.apache.hadoop.hbase.filter.FilterListBase
- toString() - Method in class org.apache.hadoop.hbase.filter.FuzzyRowFilter
- toString() - Method in class org.apache.hadoop.hbase.filter.InclusiveStopFilter
- toString() - Method in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
- toString() - Method in class org.apache.hadoop.hbase.filter.PageFilter
- toString() - Method in class org.apache.hadoop.hbase.filter.PrefixFilter
- toString() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
- toString() - Method in class org.apache.hadoop.hbase.filter.SkipFilter
- toString() - Method in class org.apache.hadoop.hbase.filter.TimestampsFilter
- toString() - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
- toString() - Method in class org.apache.hadoop.hbase.HBaseServerBase
- toString() - Method in class org.apache.hadoop.hbase.hbtop.field.FieldValue
- toString() - Method in class org.apache.hadoop.hbase.hbtop.RecordFilter
- toString() - Method in class org.apache.hadoop.hbase.hbtop.terminal.KeyPress
- toString() - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution
- toString() - Method in class org.apache.hadoop.hbase.HRegionLocation
- toString() - Method in class org.apache.hadoop.hbase.http.HttpServer
-
Return the host and port of the HttpServer, if live
- toString() - Method in class org.apache.hadoop.hbase.IndividualBytesFieldCell
- toString() - Method in class org.apache.hadoop.hbase.io.crypto.Context
- toString() - Method in class org.apache.hadoop.hbase.io.encoding.CopyKeyDataBlockEncoder
- toString() - Method in class org.apache.hadoop.hbase.io.encoding.DiffKeyDeltaEncoder
- toString() - Method in class org.apache.hadoop.hbase.io.encoding.EncodedDataBlock
- toString() - Method in class org.apache.hadoop.hbase.io.encoding.FastDiffDeltaEncoder
- toString() - Method in class org.apache.hadoop.hbase.io.encoding.PrefixKeyDeltaEncoder
- toString() - Method in class org.apache.hadoop.hbase.io.FileLink
- toString() - Method in class org.apache.hadoop.hbase.io.hadoopbackport.ThrottledInputStream
- toString() - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheKey
- toString() - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil.CachedBlocksByFile
- toString() - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
- toString() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
- toString() - Method in class org.apache.hadoop.hbase.io.hfile.CompoundBloomFilter
- toString() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
- toString() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
- toString() - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
- toString() - Method in class org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoderImpl
- toString() - Method in class org.apache.hadoop.hbase.io.hfile.HFileIndexBlockEncoderImpl
- toString() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
- toString() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
- toString() - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterImpl
- toString() - Method in class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache
- toString() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
- toString() - Method in class org.apache.hadoop.hbase.io.hfile.NoOpDataBlockEncoder
- toString() - Method in class org.apache.hadoop.hbase.io.hfile.NoOpIndexBlockEncoder.NoOpEncodedSeeker
- toString() - Method in class org.apache.hadoop.hbase.io.hfile.NoOpIndexBlockEncoder
- toString() - Method in class org.apache.hadoop.hbase.io.hfile.TinyLfuBlockCache
- toString() - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
- toString() - Method in class org.apache.hadoop.hbase.io.Reference
- toString() - Method in class org.apache.hadoop.hbase.io.TimeRange
- toString() - Method in class org.apache.hadoop.hbase.ipc.AdaptiveLifoCoDelCallQueue
- toString() - Method in class org.apache.hadoop.hbase.ipc.ServerCall
- toString() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
- toString() - Method in class org.apache.hadoop.hbase.KeyValue
- toString() - Method in class org.apache.hadoop.hbase.mapred.TableSplit
- toString() - Method in class org.apache.hadoop.hbase.mapreduce.HashTable.TableHash
- toString() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
-
Returns the details about this instance as a string.
- toString() - Method in class org.apache.hadoop.hbase.master.ClusterStatusPublisher.MulticastPublisher
- toString() - Method in class org.apache.hadoop.hbase.master.ClusterStatusPublisher
- toString() - Method in class org.apache.hadoop.hbase.master.DeadServer
- toString() - Method in class org.apache.hadoop.hbase.master.RegionPlan
- toString() - Method in class org.apache.hadoop.hbase.master.RegionState
- toString() - Method in class org.apache.hadoop.hbase.master.SplitLogManager.Task
-
Deprecated.
- toString() - Method in class org.apache.hadoop.hbase.master.SplitLogManager.TaskBatch
-
Deprecated.
- toString() - Method in enum class org.apache.hadoop.hbase.master.SplitLogManager.TerminationStatus
-
Deprecated.
- toString() - Method in class org.apache.hadoop.hbase.namequeues.BalancerDecisionDetails
- toString() - Method in class org.apache.hadoop.hbase.namequeues.BalancerRejectionDetails
- toString() - Method in class org.apache.hadoop.hbase.namequeues.request.NamedQueueGetRequest
- toString() - Method in class org.apache.hadoop.hbase.namequeues.response.NamedQueueGetResponse
- toString() - Method in class org.apache.hadoop.hbase.namequeues.RpcLogDetails
- toString() - Method in class org.apache.hadoop.hbase.namequeues.WALEventTrackerPayload
- toString() - Method in class org.apache.hadoop.hbase.NamespaceDescriptor
- toString() - Method in class org.apache.hadoop.hbase.net.Address
- toString() - Method in class org.apache.hadoop.hbase.nio.ByteBuff
- toString() - Method in class org.apache.hadoop.hbase.PerformanceEvaluation.RunResult
- toString() - Method in class org.apache.hadoop.hbase.quotas.ActivePolicyEnforcement
- toString() - Method in class org.apache.hadoop.hbase.quotas.FileArchiverNotifierImpl
- toString() - Method in class org.apache.hadoop.hbase.quotas.GlobalQuotaSettingsImpl
- toString() - Method in class org.apache.hadoop.hbase.quotas.QuotaState
- toString() - Method in class org.apache.hadoop.hbase.quotas.RateLimiter
- toString() - Method in class org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot.SpaceQuotaStatus
- toString() - Method in class org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot
- toString() - Method in class org.apache.hadoop.hbase.quotas.ThrottleSettings
- toString() - Method in class org.apache.hadoop.hbase.quotas.TimeBasedLimiter
- toString() - Method in class org.apache.hadoop.hbase.quotas.UserQuotaState
- toString() - Method in class org.apache.hadoop.hbase.RegionLocations
- toString() - Method in class org.apache.hadoop.hbase.regionserver.AbstractMemStore
- toString() - Method in class org.apache.hadoop.hbase.regionserver.BusyRegionSplitPolicy
- toString() - Method in class org.apache.hadoop.hbase.regionserver.Chunk
- toString() - Method in class org.apache.hadoop.hbase.regionserver.CompactSplit
- toString() - Method in class org.apache.hadoop.hbase.regionserver.CompositeImmutableSegment
- toString() - Method in class org.apache.hadoop.hbase.regionserver.ConstantSizeRegionSplitPolicy
- toString() - Method in class org.apache.hadoop.hbase.regionserver.CustomizedScanInfoBuilder
- toString() - Method in class org.apache.hadoop.hbase.regionserver.DelimitedKeyPrefixRegionSplitPolicy
-
Deprecated.
- toString() - Method in class org.apache.hadoop.hbase.regionserver.FlushAllStoresPolicy
- toString() - Method in class org.apache.hadoop.hbase.regionserver.FlushLargeStoresPolicy
- toString() - Method in class org.apache.hadoop.hbase.regionserver.HRegion.FlushResultImpl
- toString() - Method in class org.apache.hadoop.hbase.regionserver.HRegion.RowLockImpl
- toString() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
- toString() - Method in class org.apache.hadoop.hbase.regionserver.HStore
- toString() - Method in class org.apache.hadoop.hbase.regionserver.HStoreFile
- toString() - Method in class org.apache.hadoop.hbase.regionserver.ImmutableSegment
- toString() - Method in class org.apache.hadoop.hbase.regionserver.IncreasingToUpperBoundRegionSplitPolicy
- toString() - Method in class org.apache.hadoop.hbase.regionserver.KeyPrefixRegionSplitPolicy
-
Deprecated.
- toString() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreCompactionStrategy
- toString() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreCompactor
- toString() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreFlusher
- toString() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreSize
- toString() - Method in class org.apache.hadoop.hbase.regionserver.MultiVersionConcurrencyControl
- toString() - Method in class org.apache.hadoop.hbase.regionserver.MultiVersionConcurrencyControl.WriteEntry
- toString() - Method in class org.apache.hadoop.hbase.regionserver.ScanInfo
- toString() - Method in class org.apache.hadoop.hbase.regionserver.ScannerContext
- toString() - Method in class org.apache.hadoop.hbase.regionserver.Segment
- toString() - Method in class org.apache.hadoop.hbase.regionserver.SegmentScanner
- toString() - Method in class org.apache.hadoop.hbase.regionserver.SteppingSplitPolicy
- toString() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
- toString() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
- toString() - Method in class org.apache.hadoop.hbase.regionserver.throttle.NoLimitThroughputController
- toString() - Method in class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareCompactionThroughputController
- toString() - Method in class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareFlushThroughputController
- toString() - Method in class org.apache.hadoop.hbase.regionserver.throttle.StoreHotnessProtector
- toString() - Method in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker
- toString() - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
- toString() - Method in class org.apache.hadoop.hbase.replication.ReplicationBarrierFamilyFormat.ReplicationBarrierResult
- toString() - Method in class org.apache.hadoop.hbase.replication.ReplicationGroupOffset
- toString() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
- toString() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerDescription
- toString() - Method in class org.apache.hadoop.hbase.replication.ReplicationQueueId
- toString() - Method in class org.apache.hadoop.hbase.rest.client.Cluster
- toString() - Method in class org.apache.hadoop.hbase.rest.RowSpec
- toString() - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
- toString() - Method in class org.apache.hadoop.hbase.ScheduledChore
-
A summation of this chore in human readable format.
- toString() - Method in class org.apache.hadoop.hbase.security.User.SecureHadoopUser
- toString() - Method in class org.apache.hadoop.hbase.security.User
- toString() - Method in class org.apache.hadoop.hbase.ServerName
- toString() - Method in class org.apache.hadoop.hbase.Size
- toString() - Method in class org.apache.hadoop.hbase.SplitLogTask
-
Deprecated.
- toString() - Method in class org.apache.hadoop.hbase.StartMiniClusterOption
-
Deprecated.
- toString() - Method in class org.apache.hadoop.hbase.TableName
- toString() - Method in class org.apache.hadoop.hbase.testing.TestingHBaseClusterOption
- toString() - Method in enum class org.apache.hadoop.hbase.thrift.ImplType
-
Returns
-option
- toString() - Method in class org.apache.hadoop.hbase.thrift.TBoundedThreadPoolServer.Args
- toString() - Method in class org.apache.hadoop.hbase.tool.coprocessor.CoprocessorViolation
- toString() - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
- toString() - Method in class org.apache.hadoop.hbase.util.BloomFilterChunk
- toString() - Method in class org.apache.hadoop.hbase.util.Bytes
- toString() - Method in class org.apache.hadoop.hbase.util.compaction.MajorCompactionTTLRequest
- toString() - Method in class org.apache.hadoop.hbase.util.HashedBytes
- toString() - Method in class org.apache.hadoop.hbase.util.HbckRegionInfo
- toString() - Method in class org.apache.hadoop.hbase.util.IdLock.Entry
- toString() - Method in class org.apache.hadoop.hbase.util.ImmutableByteArray
- toString() - Method in class org.apache.hadoop.hbase.util.MapReduceExtendedCell
- toString() - Method in class org.apache.hadoop.hbase.util.NonceKey
- toString() - Method in class org.apache.hadoop.hbase.util.ObjectIntPair
- toString() - Method in class org.apache.hadoop.hbase.util.Pair
- toString() - Method in class org.apache.hadoop.hbase.util.PairOfSameType
- toString() - Method in class org.apache.hadoop.hbase.util.RegionSplitter.NumberStringSplit
- toString() - Method in class org.apache.hadoop.hbase.util.RegionSplitter.UniformSplit
- toString() - Method in class org.apache.hadoop.hbase.util.Triple
- toString() - Method in class org.apache.hadoop.hbase.wal.WAL.Entry
- toString() - Method in interface org.apache.hadoop.hbase.wal.WAL
-
Human readable identifying information about the state of this WAL.
- toString() - Method in class org.apache.hadoop.hbase.wal.WALEdit
- toString() - Method in class org.apache.hadoop.hbase.wal.WALKeyImpl
- toString() - Method in class org.apache.hadoop.hbase.zookeeper.ZKNodeTracker
- toString() - Method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.NodeAndData
-
Deprecated.
- toString() - Method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp
- toString() - Method in class org.apache.hadoop.hbase.zookeeper.ZKWatcher
- toString() - Method in class org.apache.hadoop.hbase.zookeeper.ZNodePaths
- toString(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Convert a byte[] into a string.
- toString(byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
This method will convert utf8 encoded bytes into a string.
- toString(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
This method will convert utf8 encoded bytes into a string.
- toString(byte[], String, byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Joins two byte arrays together using a separator.
- toString(int) - Method in class org.apache.hadoop.hbase.client.ImmutableScan
- toString(int) - Method in class org.apache.hadoop.hbase.client.Operation
-
Produces a string representation of this Operation.
- toString(int) - Method in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
- toString(int) - Method in class org.apache.hadoop.hbase.filter.TimestampsFilter
- toString(Collection<?>) - Static method in class org.apache.hadoop.hbase.util.PrettyPrinter
-
Pretty prints a collection of any type to a string.
- toString(Cell, boolean) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Returns a string representation of the cell
- toString(CachedBlock, long) - Static method in class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil
-
Returns The block content as String.
- toString(SnapshotProtos.SnapshotDescription) - Static method in class org.apache.hadoop.hbase.snapshot.ClientSnapshotDescriptionUtils
-
Returns a single line (no \n) representation of snapshot metadata.
- toString(BloomFilterChunk) - Static method in class org.apache.hadoop.hbase.util.BloomFilterUtil
- toStringBinary(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Write a printable representation of a byte array.
- toStringBinary(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Write a printable representation of a byte array.
- toStringBinary(ByteBuffer) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
- toStringBinary(ByteBuffer) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Converts the given byte buffer to a printable representation, from the index 0 (inclusive) to the limit (exclusive), regardless of the current position.
- toStringBinary(ByteBuffer, int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
- toStringCustomizedValues() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Returns Column family descriptor with only the customized attributes.
- toStringCustomizedValues() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
Returns Name of this table and then a map of all of the column family descriptors (with only the non-default column family attributes)
- toStringDetailed() - Method in class org.apache.hadoop.hbase.regionserver.HStoreFile
- toStringDetailed() - Method in interface org.apache.hadoop.hbase.regionserver.StoreFile
-
Returns a length description of this StoreFile, suitable for debug output
- toStringMap() - Method in class org.apache.hadoop.hbase.KeyValue
-
Produces a string map for this key/value pair.
- toStringMap() - Method in interface org.apache.hadoop.hbase.wal.WALKey
-
Produces a string map for this key.
- toStringMap(ExtendedCell) - Static method in class org.apache.hadoop.hbase.wal.WALPrettyPrinter
- toStringMap(ExtendedCell, boolean, String, String, boolean) - Static method in class org.apache.hadoop.hbase.wal.WALPrettyPrinter
- toStringMinusFileName(CachedBlock, long) - Static method in class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil
-
Returns The block content of
bc
as a String minus the filename. - toStringWithoutDomain() - Method in class org.apache.hadoop.hbase.net.Address
-
If hostname is a.b.c and the port is 123, return a:123 instead of a.b.c:123.
- toStringWithPadding(Collection<? extends KeyValue>, boolean) - Static method in class org.apache.hadoop.hbase.KeyValueTestUtil
-
toString
- toStringWithPadding(KeyValue, int, int, int, int, boolean) - Static method in class org.apache.hadoop.hbase.KeyValueTestUtil
- toStruct() - Method in class org.apache.hadoop.hbase.types.StructBuilder
-
Retrieve the
Struct
represented bythis
. - toSyncReplicationState(SyncReplicationState) - Static method in class org.apache.hadoop.hbase.client.replication.ReplicationPeerConfigUtil
- toSyncReplicationState(ReplicationProtos.SyncReplicationState) - Static method in class org.apache.hadoop.hbase.client.replication.ReplicationPeerConfigUtil
- tot_mgr_get_data_err - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
Deprecated.
- tot_mgr_get_data_nonode - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
Deprecated.
- tot_mgr_get_data_queued - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
Deprecated.
- tot_mgr_get_data_result - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
Deprecated.
- tot_mgr_get_data_retry - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
Deprecated.
- tot_mgr_heartbeat - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
Deprecated.
- tot_mgr_log_split_batch_err - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
Deprecated.
- tot_mgr_log_split_batch_start - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
Deprecated.
- tot_mgr_log_split_batch_success - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
Deprecated.
- tot_mgr_log_split_err - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
Deprecated.
- tot_mgr_log_split_success - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
Deprecated.
- tot_mgr_missing_state_in_delete - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
Deprecated.
- tot_mgr_node_already_exists - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
Deprecated.
- tot_mgr_node_create_err - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
Deprecated.
- tot_mgr_node_create_queued - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
Deprecated.
- tot_mgr_node_create_result - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
Deprecated.
- tot_mgr_node_create_retry - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
Deprecated.
- tot_mgr_node_delete_err - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
Deprecated.
- tot_mgr_node_delete_queued - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
Deprecated.
- tot_mgr_node_delete_result - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
Deprecated.
- tot_mgr_null_data - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
Deprecated.
- tot_mgr_orphan_task_acquired - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
Deprecated.
- tot_mgr_rescan - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
Deprecated.
- tot_mgr_rescan_deleted - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
Deprecated.
- tot_mgr_resubmit - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
Deprecated.
- tot_mgr_resubmit_dead_server_task - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
Deprecated.
- tot_mgr_resubmit_failed - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
Deprecated.
- tot_mgr_resubmit_force - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
Deprecated.
- tot_mgr_resubmit_threshold_reached - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
Deprecated.
- tot_mgr_resubmit_unassigned - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
Deprecated.
- tot_mgr_task_deleted - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
Deprecated.
- tot_mgr_unacquired_orphan_done - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
Deprecated.
- tot_mgr_wait_for_zk_delete - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
Deprecated.
- tot_wkr_failed_to_grab_task_exception - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
Deprecated.
- tot_wkr_failed_to_grab_task_lost_race - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
Deprecated.
- tot_wkr_failed_to_grab_task_no_data - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
Deprecated.
- tot_wkr_failed_to_grab_task_owned - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
Deprecated.
- tot_wkr_final_transition_failed - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
Deprecated.
- tot_wkr_get_data_queued - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
Deprecated.
- tot_wkr_get_data_result - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
Deprecated.
- tot_wkr_get_data_retry - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
Deprecated.
- tot_wkr_preempt_task - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
Deprecated.
- tot_wkr_task_acquired - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
Deprecated.
- tot_wkr_task_acquired_rescan - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
Deprecated.
- tot_wkr_task_done - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
Deprecated.
- tot_wkr_task_err - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
Deprecated.
- tot_wkr_task_grabing - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
Deprecated.
- tot_wkr_task_heartbeat - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
Deprecated.
- tot_wkr_task_heartbeat_failed - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
Deprecated.
- tot_wkr_task_resigned - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
Deprecated.
- toTableDescriptor(HBaseProtos.TableSchema) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Converts a TableSchema to TableDescriptor
- toTableDescriptorList(MasterProtos.GetTableDescriptorsResponse) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Get a list of TableDescriptor from GetTableDescriptorsResponse protobuf
- toTableDescriptorList(MasterProtos.ListTableDescriptorsByNamespaceResponse) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Get a list of TableDescriptor from ListTableDescriptorsByNamespaceResponse protobuf
- toTableDescriptorList(MasterProtos.ListTableDescriptorsByStateResponse) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Get a list of TableDescriptor from ListTableDescriptorsByNamespaceResponse protobuf
- toTableName(HBaseProtos.TableName) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
- toTableNameList(List<HBaseProtos.TableName>) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
- toTableRegionStatesCount(RegionStatesCount) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
- toTableRegionStatesCount(ClusterStatusProtos.RegionStatesCount) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
- toTableSchema(TableDescriptor) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Converts an TableDescriptor to TableSchema
- TOTAL_BYTES_READ - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- TOTAL_BYTES_READ_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- TOTAL_CALL_TIME_DESC - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
- TOTAL_CALL_TIME_NAME - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
- TOTAL_FAILED_ZK_CALLS - Static variable in interface org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSource
- TOTAL_FAILED_ZK_CALLS_DESC - Static variable in interface org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSource
- TOTAL_REQUEST_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- TOTAL_REQUEST_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- TOTAL_ROW_ACTION_REQUEST_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- TOTAL_ROW_ACTION_REQUEST_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- totalBuffered - Variable in class org.apache.hadoop.hbase.wal.BoundedEntryBuffers
- totalByteSize - Variable in class org.apache.hadoop.hbase.io.hfile.CompoundBloomFilterBase
- totalCompactedFilesSize() - Method in class org.apache.hadoop.hbase.regionserver.CreateStoreFileWriterParams
- totalCompactedFilesSize(long) - Method in class org.apache.hadoop.hbase.regionserver.CreateStoreFileWriterParams
- totalKeyCount - Variable in class org.apache.hadoop.hbase.io.hfile.CompoundBloomFilterBase
-
The total number of keys in all chunks
- totalKeyLength - Variable in class org.apache.hadoop.hbase.io.hfile.HFileWriterImpl
-
Used for calculating the average key length.
- totalLengthWithMvccVersion(Iterable<? extends KeyValue>, boolean) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
- totalLogSize - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
The total size of wal
- totalMaxKeys - Variable in class org.apache.hadoop.hbase.io.hfile.CompoundBloomFilterBase
- totalOpTimeMs - Variable in class org.apache.hadoop.hbase.util.MultiThreadedAction
- totalSkippedEdits - Variable in class org.apache.hadoop.hbase.wal.BoundedRecoveredHFilesOutputSink
- totalUncompressedBytes - Variable in class org.apache.hadoop.hbase.io.hfile.HFileWriterImpl
-
Total uncompressed bytes, maybe calculate a compression ratio later.
- totalValueLength - Variable in class org.apache.hadoop.hbase.io.hfile.HFileWriterImpl
-
Used for calculating the average value length.
- toText(Message) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Returns A String version of the passed in
msg
- toThrottleType(QuotaProtos.ThrottleType) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Convert a protocol buffer ThrottleType to a client ThrottleType
- toTimedQuota(long, TimeUnit, QuotaScope) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Build a protocol buffer TimedQuota
- toTimeRange(TimeRange) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
- toTimeRange(HBaseProtos.TimeRange) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
- toTimeUnit(HBaseProtos.TimeUnit) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Convert a protocol buffer TimeUnit to a client TimeUnit
- toType(byte) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
- toTypeByte(Cell.Type) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
- touch() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
Calling this method in strategic locations where HFileBlocks are referenced may help diagnose potential buffer leaks.
- touch() - Method in class org.apache.hadoop.hbase.nio.ByteBuff
-
Calling this method in strategic locations where ByteBuffs are referenced may help diagnose potential buffer leaks.
- touch() - Method in interface org.apache.hadoop.hbase.nio.HBaseReferenceCounted
- touch() - Method in class org.apache.hadoop.hbase.nio.RefCnt
- touch(Object) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
- touch(Object) - Method in class org.apache.hadoop.hbase.nio.ByteBuff
- touch(Object) - Method in interface org.apache.hadoop.hbase.nio.HBaseReferenceCounted
- touch(Object) - Method in class org.apache.hadoop.hbase.nio.RefCnt
- toUnassignRegionsRequest(List<String>, boolean, boolean) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
- toUserMetrics(ClusterStatusProtos.UserLoad) - Static method in class org.apache.hadoop.hbase.UserMetricsBuilder
- toUserMetrics(UserMetrics) - Static method in class org.apache.hadoop.hbase.UserMetricsBuilder
- toViolationPolicy(QuotaProtos.SpaceViolationPolicy) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
Converts a protocol buffer SpaceViolationPolicy to a client SpaceViolationPolicy.
- toWriteAppends - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
- tr - Variable in class org.apache.hadoop.hbase.regionserver.querymatcher.UserScanQueryMatcher
- TRACE_LOG_MAX_LENGTH - Static variable in class org.apache.hadoop.hbase.ipc.RpcServer
- trackDelete(ExtendedCell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.CompactionScanQueryMatcher
- TRACKER_IMPL - Static variable in class org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileTrackerFactory
- trackPeerConfigChanges(ReplicationPeerConfigListener) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeer
-
Deprecated.since 2.1.0 and will be removed in 4.0.0. Use
ReplicationPeer.registerPeerConfigListener(ReplicationPeerConfigListener)
instead. - trackWroteKeys - Variable in class org.apache.hadoop.hbase.util.MultiThreadedWriterBase
-
Enable this if used in conjunction with a concurrent reader.
- trailer - Variable in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
- trailer - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractProtobufLogWriter
- trailer - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractProtobufWALReader
- TRAILER - Enum constant in enum class org.apache.hadoop.hbase.io.hfile.BlockType
-
Fixed file trailer, both versions (always just a magic string)
- trailerPresent - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractProtobufWALReader
- trailerSize() - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractProtobufWALReader
- trailerWarnSize - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractProtobufLogWriter
- trailerWarnSize - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractProtobufWALReader
- trailerWritten - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractProtobufLogWriter
- transform(float[][]) - Method in class org.apache.hadoop.hbase.master.RegionPlacementMaintainer.RandomizedMatrix
-
Copy a given matrix into a new matrix, transforming each row index and each column index according to the randomization scheme that was created at construction time.
- transformCell(Cell) - Method in class org.apache.hadoop.hbase.filter.Filter
-
Give the filter a chance to transform the passed Cell.
- transformCell(Cell) - Method in class org.apache.hadoop.hbase.filter.FilterBase
-
By default no transformation takes place Give the filter a chance to transform the passed Cell.
- transformCell(Cell) - Method in class org.apache.hadoop.hbase.filter.FilterList
- transformCell(Cell) - Method in class org.apache.hadoop.hbase.filter.FilterListBase
-
For FilterList, we can consider a filter list as a node in a tree.
- transformCell(Cell) - Method in class org.apache.hadoop.hbase.filter.FilterWrapper
- transformCell(Cell) - Method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter
- transformCell(Cell) - Method in class org.apache.hadoop.hbase.filter.SkipFilter
- transformCell(Cell) - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
- transformClusterKey(String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKConfig
-
Separate the given key into the three configurations it should contain: hbase.zookeeper.quorum, hbase.zookeeper.client.port and zookeeper.znode.parent
- transitionTable(TableName, SpaceQuotaSnapshot) - Method in interface org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshotNotifier
-
Informs the cluster of the current state of a space quota for a table.
- transitionTable(TableName, SpaceQuotaSnapshot) - Method in class org.apache.hadoop.hbase.quotas.TableSpaceQuotaSnapshotNotifier
- transitionToFieldScreen(Screen, Terminal) - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenPresenter
- transitionToHelpScreen(Screen, Terminal) - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenPresenter
- transitionToModeScreen(Screen, Terminal) - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenPresenter
- transitionToNextScreen() - Method in class org.apache.hadoop.hbase.hbtop.screen.field.FieldScreenPresenter
- transitionToNextScreen() - Method in class org.apache.hadoop.hbase.hbtop.screen.help.HelpScreenPresenter
- transitionToNextScreen(boolean) - Method in class org.apache.hadoop.hbase.hbtop.screen.mode.ModeScreenPresenter
- transitPeerSyncReplicationState(String) - Method in class org.apache.hadoop.hbase.replication.FSReplicationPeerStorage
- transitPeerSyncReplicationState(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeers
- transitPeerSyncReplicationState(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeerStorage
-
Overwrite the sync replication state with the new sync replication state which is set with the
ReplicationPeerStorage.setPeerNewSyncReplicationState(String, SyncReplicationState)
method above, and clear the new sync replication state. - transitPeerSyncReplicationState(String) - Method in class org.apache.hadoop.hbase.replication.ZKReplicationPeerStorage
- transitReplicationPeerSyncReplicationState(String, SyncReplicationState) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Transit current cluster to a new state in a synchronous replication peer.
- transitReplicationPeerSyncReplicationState(String, SyncReplicationState) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Transit current cluster to a new state in a synchronous replication peer.
- transitReplicationPeerSyncReplicationState(String, SyncReplicationState) - Method in class org.apache.hadoop.hbase.master.HMaster
- transitReplicationPeerSyncReplicationState(String, SyncReplicationState) - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Set current cluster state for a synchronous replication peer.
- transitReplicationPeerSyncReplicationState(RpcController, ReplicationProtos.TransitReplicationPeerSyncReplicationStateRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- transitReplicationPeerSyncReplicationStateAsync(String, SyncReplicationState) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Transit current cluster to a new state in a synchronous replication peer.
- transitSyncReplicationState() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerImpl
- translatePFFE(Throwable) - Static method in class org.apache.hadoop.hbase.exceptions.ClientExceptionsUtil
-
Translates exception for preemptive fast fail checks.
- TREEMAP - Static variable in class org.apache.hadoop.hbase.util.ClassSize
-
Overhead for TreeMap
- trigger() - Method in class org.apache.hadoop.hbase.errorhandling.TimeoutExceptionInjector
-
Trigger the timer immediately.
- triggerMajorCompaction() - Method in class org.apache.hadoop.hbase.regionserver.HStore
- triggerNow() - Method in class org.apache.hadoop.hbase.ScheduledChore
-
Returns false when the Chore is not currently scheduled with a ChoreService
- org.apache.hadoop.hbase.util.Triple<A,
B, C> - Class in org.apache.hadoop.hbase.util -
Utility class to manage a triple.
- Triple() - Constructor for class org.apache.hadoop.hbase.util.Triple
- Triple(A, B, C) - Constructor for class org.apache.hadoop.hbase.util.Triple
- TRUE - Enum constant in enum class org.apache.hadoop.hbase.KeepDeletedCells
-
Deleted Cells are retained until they are removed by other means such TTL or VERSIONS.
- TRUE - Enum constant in enum class org.apache.hadoop.hbase.snapshot.ExportSnapshot.ChecksumComparison
- truncateRegion(byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Truncate an individual region.
- truncateRegion(byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Truncate an individual region.
- truncateRegion(RegionInfo, long, long) - Method in class org.apache.hadoop.hbase.master.HMaster
- truncateRegion(RegionInfo, long, long) - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Truncate region
- truncateRegion(RpcController, MasterProtos.TruncateRegionRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- truncateRegionAsync(byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Truncate an individual region.
- truncateTable(TableName) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Truncate a table using the admin command.
- truncateTable(TableName, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Truncate a table.
- truncateTable(TableName, boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Truncate a table.
- truncateTable(TableName, boolean) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Truncate a table using the admin command.
- truncateTable(TableName, boolean, long, long) - Method in class org.apache.hadoop.hbase.master.HMaster
- truncateTable(TableName, boolean, long, long) - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Truncate a table
- truncateTable(RpcController, MasterProtos.TruncateTableRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- truncateTableAsync(TableName, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Truncate the table but does not block and wait for it to be completely enabled.
- org.apache.hadoop.hbase.exceptions.TrustManagerException - Exception in org.apache.hadoop.hbase.exceptions
- TrustManagerException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.TrustManagerException
- TrustManagerException(Throwable) - Constructor for exception org.apache.hadoop.hbase.exceptions.TrustManagerException
- trustStore(String, String, String) - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
- tryAddExcludeDN(DatanodeInfo, String) - Method in class org.apache.hadoop.hbase.io.asyncfs.monitor.ExcludeDatanodeManager
-
Try to add a datanode to the regionserver excluding cache
- tryCommitRecoveredHFile(Path) - Method in class org.apache.hadoop.hbase.regionserver.HStore
- tryDropDelete(ExtendedCell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.DropDeletesCompactionScanQueryMatcher
- tryLockEntry(long, long) - Method in class org.apache.hadoop.hbase.util.IdLock
-
Blocks until the lock corresponding to the given id is acquired.
- tryParseAsConnectionURI(String) - Static method in class org.apache.hadoop.hbase.client.ConnectionRegistryFactory
- tryRegionServerReport(long, long) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
- trySkipToNextColumn(ExtendedCell) - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
See
StoreScanner.trySkipToNextRow(ExtendedCell)
- trySkipToNextRow(ExtendedCell) - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
See if we should actually SEEK or rather just SKIP to the next Cell (see HBASE-13109).
- tryUpdateAndGetMetaTableDescriptor(Configuration, FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSTableDescriptors
- tryUpdateMetaTableDescriptor(Configuration) - Static method in class org.apache.hadoop.hbase.util.FSTableDescriptors
- ts - Variable in class org.apache.hadoop.hbase.client.Mutation
- ts - Variable in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
-
Timestamp for all inserted rows
- ts - Variable in class org.apache.hadoop.hbase.regionserver.querymatcher.NewVersionBehaviorTracker.DeleteVersionsNode
- tserver - Variable in class org.apache.hadoop.hbase.thrift.ThriftServer
- org.apache.hadoop.hbase.mapreduce.TsvImporterMapper - Class in org.apache.hadoop.hbase.mapreduce
-
Write table content out to files in hdfs.
- TsvImporterMapper() - Constructor for class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
- org.apache.hadoop.hbase.mapreduce.TsvImporterTextMapper - Class in org.apache.hadoop.hbase.mapreduce
-
Write table content out to map output files.
- TsvImporterTextMapper() - Constructor for class org.apache.hadoop.hbase.mapreduce.TsvImporterTextMapper
- TsvParser(String, String) - Constructor for class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
- ttl - Variable in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
- TTL - Enum constant in enum class org.apache.hadoop.hbase.KeepDeletedCells
-
Deleted Cells are retained until the delete marker expires due to TTL.
- TTL - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
- TTL_TAG_TYPE - Static variable in class org.apache.hadoop.hbase.TagType
- tune(HeapMemoryManager.TunerContext) - Method in interface org.apache.hadoop.hbase.regionserver.HeapMemoryTuner
-
Perform the heap memory tuning operation.
- TunerContext() - Constructor for class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerContext
- TunerResult(boolean) - Constructor for class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerResult
- tuningPeriod - Variable in class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareThroughputController
- turnOffMoveMode() - Method in class org.apache.hadoop.hbase.hbtop.screen.field.FieldScreenPresenter
- turnOnMoveMode() - Method in class org.apache.hadoop.hbase.hbtop.screen.field.FieldScreenPresenter
- TWENTY_FIFTH_PERCENTILE_METRIC_NAME - Static variable in interface org.apache.hadoop.metrics2.MetricHistogram
- TWO - Enum constant in enum class org.apache.hadoop.hbase.thrift.ThriftMetrics.ThriftServerType
- type - Variable in class org.apache.hadoop.hbase.ExtendedCellBuilderImpl
- type() - Method in class org.apache.hadoop.hbase.client.MultiResponse
- type() - Method in class org.apache.hadoop.hbase.client.SingleResponse
- TYPE_KEY - Static variable in class org.apache.hadoop.hbase.util.JSONMetricUtil
- TYPE_LENGTH_SIZE - Static variable in interface org.apache.hadoop.hbase.Tag
- TYPE_SIZE - Static variable in class org.apache.hadoop.hbase.KeyValue
-
Size of the key type field in bytes
- typeA - Variable in class org.apache.hadoop.hbase.types.Union2
- typeB - Variable in class org.apache.hadoop.hbase.types.Union2
- typeC - Variable in class org.apache.hadoop.hbase.types.Union3
- typeD - Variable in class org.apache.hadoop.hbase.types.Union4
- types - Variable in class org.apache.hadoop.hbase.types.StructIterator
U
- ugi - Variable in class org.apache.hadoop.hbase.security.User
- unackedAppends - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
- unassign(byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Unassign a Region.
- unassign(byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Unassign a region from current hosting regionserver.
- unassign(byte[]) - Method in class org.apache.hadoop.hbase.MockRegionServerServices
- unassign(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
- unassign(byte[]) - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
Unassign the given region from the current regionserver and assign it randomly.
- unassign(byte[], boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Deprecated.since 2.4.0 and will be removed in 4.0.0. Use
Admin.unassign(byte[])
instead. - unassign(byte[], boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Deprecated.since 2.4.0 and will be removed in 4.0.0. Use
AsyncAdmin.unassign(byte[])
instead. - UNASSIGN_METRIC_PREFIX - Static variable in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
- Unassigned(ServerName) - Constructor for class org.apache.hadoop.hbase.SplitLogTask.Unassigned
-
Deprecated.
- unassignRegion(byte[]) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Unassign the named region.
- unassignRegion(String) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Unassign the named region.
- unassignRegion(RpcController, MasterProtos.UnassignRegionRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- unassignRegionByRow(byte[], RegionLocator) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Closes the region containing the given row.
- unassignRegionByRow(String, RegionLocator) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Closes the region containing the given row.
- unassigns(List<String>) - Method in interface org.apache.hadoop.hbase.client.Hbck
- unassigns(List<String>, boolean) - Method in interface org.apache.hadoop.hbase.client.Hbck
- unassigns(List<String>, boolean, boolean) - Method in class org.apache.hadoop.hbase.client.HBaseHbck
- unassigns(List<String>, boolean, boolean) - Method in interface org.apache.hadoop.hbase.client.Hbck
-
Like
Admin.unassign(byte[], boolean)
but 'raw' in that it can do more than one Region at a time -- good if many Regions to offline -- and it will schedule the assigns even in the case where Master is initializing (as long as the ProcedureExecutor is up). - unassigns(RpcController, MasterProtos.UnassignsRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
A 'raw' version of unassign that does bulk and can skirt Master state checks if override is set; i.e.
- UNBLOCKED_FLUSH_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSource
- UNBLOCKED_FLUSH_GAUGE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSource
- UNBLOCKED_FLUSH_GAUGE_NAME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSource
- UNBLOCKED_FLUSH_NAME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSource
- unblockUpdates() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
- unbuffer() - Method in class org.apache.hadoop.hbase.io.FileLink.FileLinkInputStream
- unbuffer() - Method in class org.apache.hadoop.hbase.io.FSDataInputStreamWrapper
-
This will free sockets and file descriptors held by the stream only when the stream implements org.apache.hadoop.fs.CanUnbuffer.
- unbufferStream() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
-
To close the stream's socket.
- unbufferStream() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
- uncompress(ByteString, Enum) - Method in interface org.apache.hadoop.hbase.regionserver.wal.WALCellCodec.ByteStringUncompressor
- UNCOMPRESSED_STORE_FILE_SIZE - Enum constant in enum class org.apache.hadoop.hbase.hbtop.field.Field
- org.apache.hadoop.hbase.io.hfile.UncompressedBlockSizePredicator - Class in org.apache.hadoop.hbase.io.hfile
-
This BlockCompressedSizePredicator implementation doesn't actually performs any predicate and simply returns true on
shouldFinishBlock
. - UncompressedBlockSizePredicator() - Constructor for class org.apache.hadoop.hbase.io.hfile.UncompressedBlockSizePredicator
- uncompressTags(InputStream, byte[], int, int) - Method in class org.apache.hadoop.hbase.io.TagCompressionContext
-
Uncompress tags from the InputStream and writes to the destination array.
- uncompressTags(InputStream, ByteBuffer, int) - Method in class org.apache.hadoop.hbase.io.TagCompressionContext
-
Uncompress tags from the InputStream and writes to the destination buffer.
- uncompressTags(ByteBuff, byte[], int, int) - Method in class org.apache.hadoop.hbase.io.TagCompressionContext
-
Uncompress tags from the input ByteBuffer and writes to the destination array.
- UNDEFINED - Static variable in class org.apache.hadoop.hbase.client.RegionInfoBuilder
- UNDELETED_REPLICATION_QUEUE - Enum constant in enum class org.apache.hadoop.hbase.util.HbckErrorReporter.ERROR_CODE
-
Deprecated.
- unencodedDataSizeWritten - Variable in class org.apache.hadoop.hbase.io.encoding.EncodingState
- org.apache.hadoop.hbase.exceptions.UnexpectedStateException - Exception in org.apache.hadoop.hbase.exceptions
- UnexpectedStateException() - Constructor for exception org.apache.hadoop.hbase.exceptions.UnexpectedStateException
- UnexpectedStateException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.UnexpectedStateException
- UnexpectedStateException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.exceptions.UnexpectedStateException
- UnexpectedStateException(Throwable) - Constructor for exception org.apache.hadoop.hbase.exceptions.UnexpectedStateException
- unforcedResubmits - Variable in class org.apache.hadoop.hbase.master.SplitLogManager.Task
-
Deprecated.
- UNIFIED_ENCODED_BLOCKSIZE_RATIO - Static variable in class org.apache.hadoop.hbase.io.hfile.HFileWriterImpl
-
if this feature is enabled, preCalculate encoded data size before real encoding happens
- UniformSplit() - Constructor for class org.apache.hadoop.hbase.util.RegionSplitter.UniformSplit
- UNINITIALIZED - Static variable in class org.apache.hadoop.hbase.regionserver.Chunk
- UNINSTALLED - Enum constant in enum class org.apache.hadoop.hbase.Coprocessor.State
- org.apache.hadoop.hbase.types.Union2<A,
B> - Class in org.apache.hadoop.hbase.types -
The
Union
family ofDataType
s encode one of a fixed set ofObject
s. - Union2(DataType<A>, DataType<B>) - Constructor for class org.apache.hadoop.hbase.types.Union2
-
Create an instance of
Union2
over the set of specified types. - org.apache.hadoop.hbase.types.Union3<A,
B, C> - Class in org.apache.hadoop.hbase.types -
The
Union
family ofDataType
s encode one of a fixed collection of Objects. - Union3(DataType<A>, DataType<B>, DataType<C>) - Constructor for class org.apache.hadoop.hbase.types.Union3
-
Create an instance of
Union3
over the set of specified types. - org.apache.hadoop.hbase.types.Union4<A,
B, C, D> - Class in org.apache.hadoop.hbase.types -
The
Union
family ofDataType
s encode one of a fixed collection of Objects. - Union4(DataType<A>, DataType<B>, DataType<C>, DataType<D>) - Constructor for class org.apache.hadoop.hbase.types.Union4
-
Create an instance of
Union4
over the set of specified types. - UNITTEST - Static variable in class org.apache.hadoop.hbase.HBaseInterfaceAudience
- Unknown - Enum constant in enum class org.apache.hadoop.hbase.hbtop.terminal.KeyPress.Type
- UNKNOWN - Enum constant in enum class org.apache.hadoop.hbase.io.hfile.BlockType.BlockCategory
- UNKNOWN - Enum constant in enum class org.apache.hadoop.hbase.master.ServerManager.ServerLiveState
- UNKNOWN - Enum constant in enum class org.apache.hadoop.hbase.util.HbckErrorReporter.ERROR_CODE
-
Deprecated.
- UNKNOWN - Static variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
- UNKNOWN_NUM_UNIQUES - Static variable in class org.apache.hadoop.hbase.regionserver.CellSet
- UNKNOWN_RACK - Static variable in class org.apache.hadoop.hbase.master.RackManager
- UNKNOWN_SERVER - Enum constant in enum class org.apache.hadoop.hbase.util.HbckErrorReporter.ERROR_CODE
-
Deprecated.
- UNKNOWN_SERVER_OPEN_REGIONS - Static variable in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
- UNKNOWN_SERVER_REGIONS - Static variable in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
- UNKNOWN_SERVER_REGIONS_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
- UNKNOWN_SERVERNAME - Static variable in class org.apache.hadoop.hbase.ServerName
-
What to use if server name is unknown.
- UNKNOWN_SERVERS - Enum constant in enum class org.apache.hadoop.hbase.ClusterMetrics.Option
-
metrics about unknown region servers
- org.apache.hadoop.hbase.exceptions.UnknownProtocolException - Exception in org.apache.hadoop.hbase.exceptions
-
An error requesting an RPC protocol that the server is not serving.
- UnknownProtocolException(Class<?>) - Constructor for exception org.apache.hadoop.hbase.exceptions.UnknownProtocolException
- UnknownProtocolException(Class<?>, String) - Constructor for exception org.apache.hadoop.hbase.exceptions.UnknownProtocolException
- UnknownProtocolException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.UnknownProtocolException
- org.apache.hadoop.hbase.UnknownRegionException - Exception in org.apache.hadoop.hbase
-
Thrown when we are asked to operate on a region we know nothing about.
- UnknownRegionException(String) - Constructor for exception org.apache.hadoop.hbase.UnknownRegionException
-
Constructs a new UnknownRegionException with the specified detail message.
- UnknownRegionException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.UnknownRegionException
-
Constructs a new UnknownRegionException with the specified detail message and cause.
- unknownScannerException() - Method in interface org.apache.hadoop.hbase.metrics.ExceptionTrackingSource
- unknownScannerException() - Method in class org.apache.hadoop.hbase.metrics.ExceptionTrackingSourceImpl
- org.apache.hadoop.hbase.UnknownScannerException - Exception in org.apache.hadoop.hbase
-
Thrown if a region server is passed an unknown scanner ID.
- UnknownScannerException() - Constructor for exception org.apache.hadoop.hbase.UnknownScannerException
- UnknownScannerException(String) - Constructor for exception org.apache.hadoop.hbase.UnknownScannerException
- UnknownScannerException(String, Exception) - Constructor for exception org.apache.hadoop.hbase.UnknownScannerException
- org.apache.hadoop.hbase.ipc.UnknownServiceException - Exception in org.apache.hadoop.hbase.ipc
- org.apache.hadoop.hbase.snapshot.UnknownSnapshotException - Exception in org.apache.hadoop.hbase.snapshot
-
Exception thrown when we get a request for a snapshot we don't recognize.
- UnknownSnapshotException(String) - Constructor for exception org.apache.hadoop.hbase.snapshot.UnknownSnapshotException
- UnknownSnapshotException(String, Exception) - Constructor for exception org.apache.hadoop.hbase.snapshot.UnknownSnapshotException
- unload() - Method in class org.apache.hadoop.hbase.util.RegionMover
-
Unload regions from given
RegionMover.hostname
using ack/noAck mode andRegionMover.maxthreads
.In noAck mode we do not make sure that region is successfully online on the target region server,hence it is best effort.We do not unload regions to hostnames given inRegionMover.excludeFile
. - unloadFromRack() - Method in class org.apache.hadoop.hbase.util.RegionMover
-
Unload regions from given
RegionMover.hostname
using ack/noAck mode andRegionMover.maxthreads
.In noAck mode we do not make sure that region is successfully online on the target region server,hence it is best effort.We do not unload regions to hostnames given inRegionMover.excludeFile
. - unlock() - Method in class org.apache.hadoop.hbase.client.locking.EntityLock
- unquoteHtmlChars(String) - Static method in class org.apache.hadoop.hbase.http.HtmlQuoting
-
Remove HTML quoting from a string.
- unregisterAllListeners() - Method in class org.apache.hadoop.hbase.zookeeper.ZKWatcher
-
Clean all existing listeners
- unregisterFlushRequestListener(FlushRequestListener) - Method in interface org.apache.hadoop.hbase.regionserver.FlushRequester
-
Unregister the given FlushRequestListener
- unregisterFlushRequestListener(FlushRequestListener) - Method in class org.apache.hadoop.hbase.regionserver.MemStoreFlusher
-
Unregister the listener from MemstoreFlushListeners
- unregisterListener(ServerListener) - Method in class org.apache.hadoop.hbase.master.ServerManager
-
Remove the listener from the notification list.
- unregisterListener(ZKListener) - Method in class org.apache.hadoop.hbase.zookeeper.ZKWatcher
- unregisterWALActionsListener(WALActionsListener) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
- unregisterWALActionsListener(WALActionsListener) - Method in interface org.apache.hadoop.hbase.wal.WAL
-
Unregisters WALActionsListener
- UNSAFE_HBASE_CLIENT_KERBEROS_HOSTNAME_DISABLE_REVERSEDNS - Static variable in class org.apache.hadoop.hbase.security.SecurityConstants
-
This config is for experts: don't set its value unless you really know what you are doing.
- UNSAFE_RS_HOSTNAME_KEY - Static variable in class org.apache.hadoop.hbase.util.DNS
- UNSAFE_STREAM_CAPABILITY_ENFORCE - Static variable in class org.apache.hadoop.hbase.util.CommonFSUtils
-
Parameter to disable stream capability enforcement checks
- UNSAFE_UNALIGNED - Static variable in class org.apache.hadoop.hbase.util.ByteBufferUtils
- org.apache.hadoop.hbase.util.UnsafeAccess - Class in org.apache.hadoop.hbase.util
- unset() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.Cell
- unset() - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Nullifies this ByteRange.
- unset() - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
- unset() - Method in class org.apache.hadoop.hbase.util.SimpleByteRange
- unset() - Method in class org.apache.hadoop.hbase.util.SimpleMutableByteRange
- unset() - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
- unset() - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
- unset(String) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
- UNSET_HASH_VALUE - Static variable in class org.apache.hadoop.hbase.util.AbstractByteRange
- unsetCurrentCall() - Static method in class org.apache.hadoop.hbase.ipc.RpcServer
-
Used by
RegionProcedureStore
. - unsignedBinarySearch(byte[], int, int, byte) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Search sorted array "a" for byte "key".
- unsignedCopyAndIncrement(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Treat the byte[] as an unsigned series of bytes, most significant bits first.
- UNSUPPORTED_OPTION - Enum constant in enum class org.apache.hadoop.hbase.util.HbckErrorReporter.ERROR_CODE
-
Deprecated.
- org.apache.hadoop.hbase.ipc.UnsupportedCellCodecException - Exception in org.apache.hadoop.hbase.ipc
- UnsupportedCellCodecException() - Constructor for exception org.apache.hadoop.hbase.ipc.UnsupportedCellCodecException
- UnsupportedCellCodecException(String) - Constructor for exception org.apache.hadoop.hbase.ipc.UnsupportedCellCodecException
- UnsupportedCellCodecException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.ipc.UnsupportedCellCodecException
- org.apache.hadoop.hbase.ipc.UnsupportedCompressionCodecException - Exception in org.apache.hadoop.hbase.ipc
- UnsupportedCompressionCodecException() - Constructor for exception org.apache.hadoop.hbase.ipc.UnsupportedCompressionCodecException
- UnsupportedCompressionCodecException(String) - Constructor for exception org.apache.hadoop.hbase.ipc.UnsupportedCompressionCodecException
- UnsupportedCompressionCodecException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.ipc.UnsupportedCompressionCodecException
- org.apache.hadoop.hbase.ipc.UnsupportedCryptoException - Exception in org.apache.hadoop.hbase.ipc
- UnsupportedCryptoException() - Constructor for exception org.apache.hadoop.hbase.ipc.UnsupportedCryptoException
- UnsupportedCryptoException(String) - Constructor for exception org.apache.hadoop.hbase.ipc.UnsupportedCryptoException
- UnsupportedCryptoException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.ipc.UnsupportedCryptoException
- unthrottleNamespace(String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
-
Remove the throttling for the specified namespace.
- unthrottleNamespaceByThrottleType(String, ThrottleType) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
-
Remove the throttling for the specified namespace by throttle type.
- unthrottleRegionServer(String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
-
Remove the throttling for the specified region server.
- unthrottleRegionServerByThrottleType(String, ThrottleType) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
-
Remove the throttling for the specified region server by throttle type.
- unthrottleTable(TableName) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
-
Remove the throttling for the specified table.
- unthrottleTableByThrottleType(TableName, ThrottleType) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
-
Remove the throttling for the specified table.
- unthrottleUser(String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
-
Remove the throttling for the specified user.
- unthrottleUser(String, String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
-
Remove the throttling for the specified user on the specified namespace.
- unthrottleUser(String, TableName) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
-
Remove the throttling for the specified user on the specified table.
- unthrottleUserByThrottleType(String, String, ThrottleType) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
-
Remove the throttling for the specified user on the specified namespace.
- unthrottleUserByThrottleType(String, ThrottleType) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
-
Remove the throttling for the specified user.
- unthrottleUserByThrottleType(String, TableName, ThrottleType) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
-
Remove the throttling for the specified user on the specified table.
- until(long) - Static method in class org.apache.hadoop.hbase.io.TimeRange
-
Represents the time interval [0, maxStamp)
- unwrap(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.crypto.aes.CryptoAES
-
Decrypts input data.
- unwrap(byte[], int, int) - Method in class org.apache.hadoop.hbase.security.HBaseSaslRpcServer
- unwrap(byte[], int, int) - Method in interface org.apache.hadoop.hbase.security.SaslUnwrapHandler.Unwrapper
- unwrap(Throwable) - Static method in class org.apache.hadoop.hbase.security.HBaseSaslRpcServer
-
Unwrap InvalidToken exception, otherwise return the one passed in.
- unwrap(Throwable) - Static method in class org.apache.hadoop.hbase.thrift.ThriftMetrics
- unwrapCompletionException(Throwable) - Static method in class org.apache.hadoop.hbase.util.FutureUtils
-
Get the cause of the
Throwable
if it is aCompletionException
. - unwrapKey(Configuration, byte[]) - Static method in class org.apache.hadoop.hbase.security.EncryptionUtil
-
Helper for
EncryptionUtil.unwrapKey(Configuration, String, byte[])
which automatically uses the configured master and alternative keys, rather than having to specify a key type to unwrap with. - unwrapKey(Configuration, String, byte[]) - Static method in class org.apache.hadoop.hbase.security.EncryptionUtil
-
Unwrap a key by decrypting it with the secret key of the given subject.
- unwrapRemoteException() - Method in exception org.apache.hadoop.hbase.ipc.RemoteWithExtrasException
- unwrapWALKey(Configuration, String, byte[]) - Static method in class org.apache.hadoop.hbase.security.EncryptionUtil
-
Unwrap a wal key by decrypting it with the secret key of the given subject.
- UNWRITABLE_TIME_DESC - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
- UNWRITABLE_TIME_NAME - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
- unwritableTime(long) - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
- unwritableTime(long) - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceImpl
- update() - Method in interface org.apache.hadoop.hbase.regionserver.querymatcher.DeleteTracker
-
Called at the end of every StoreFile.
- update() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.NewVersionBehaviorTracker
- update() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanDeleteTracker
- update(byte[], RegionLoadStats) - Method in class org.apache.hadoop.hbase.client.backoff.ServerStatistics
-
Good enough attempt.
- update(int) - Method in interface org.apache.hadoop.hbase.metrics.Histogram
-
Adds a new value to the distribution.
- update(long) - Method in interface org.apache.hadoop.hbase.metrics.Histogram
-
Adds a new value to the distribution.
- update(long, TimeUnit) - Method in interface org.apache.hadoop.hbase.metrics.Timer
-
Update the timer with the given duration in given time unit.
- update(Configuration) - Method in class org.apache.hadoop.hbase.regionserver.throttle.StoreHotnessProtector
- update(RegionLoadStats) - Method in class org.apache.hadoop.hbase.client.backoff.ServerStatistics.RegionStatistics
- update(RegionLoadStats) - Method in class org.apache.hadoop.hbase.client.MetricsConnection.RegionStats
- update(TableDescriptor) - Method in interface org.apache.hadoop.hbase.TableDescriptors
-
Add or update descriptor.
- update(TableDescriptor, boolean) - Method in interface org.apache.hadoop.hbase.TableDescriptors
-
Add or update descriptor
- update(TableDescriptor, boolean) - Method in class org.apache.hadoop.hbase.util.FSTableDescriptors
- update(CachedBlock) - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil.CachedBlocksByFile
-
Returns True if full....
- update(QuotaLimiter, QuotaLimiter) - Static method in class org.apache.hadoop.hbase.quotas.QuotaLimiterFactory
- update(QuotaState) - Method in class org.apache.hadoop.hbase.quotas.QuotaState
-
Perform an update of the quota info based on the other quota info object.
- update(QuotaState) - Method in class org.apache.hadoop.hbase.quotas.UserQuotaState
-
Perform an update of the quota state based on the other quota state object.
- update(RateLimiter) - Method in class org.apache.hadoop.hbase.quotas.RateLimiter
-
Sets the current instance of RateLimiter to a new values.
- update(TimeBasedLimiter) - Method in class org.apache.hadoop.hbase.quotas.TimeBasedLimiter
- updateAppend() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegion
- updateAppend() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
-
Update related counts of appends.
- updateAppend() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionSourceImpl
- updateAppend(long, long) - Method in class org.apache.hadoop.hbase.regionserver.metrics.MetricsTableRequests
-
Update the Append time histogram.
- updateAppend(long, long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
Update the Append time histogram.
- updateAppend(long, long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
- updateAppend(long, long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsUserAggregate
- updateAppend(long, long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsUserAggregateImpl
- updateAppend(long, long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsUserSource
- updateAppend(long, long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsUserSourceImpl
- updateAppend(HRegion, long, long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
- updateAssignmentPlan(FavoredNodesPlan) - Method in class org.apache.hadoop.hbase.master.RegionPlacementMaintainer
- updateAssignmentPlanToMeta(FavoredNodesPlan) - Method in class org.apache.hadoop.hbase.master.RegionPlacementMaintainer
-
Update the assignment plan into hbase:meta
- updateBalancerLoadInfo(Map<TableName, Map<ServerName, List<RegionInfo>>>) - Method in interface org.apache.hadoop.hbase.master.LoadBalancer
-
In some scenarios, Balancer needs to update internal status or information according to the current tables load
- updateBalancerLoadInfo(Map<TableName, Map<ServerName, List<RegionInfo>>>) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupBasedLoadBalancer
- updateBalancerStatus(boolean) - Method in interface org.apache.hadoop.hbase.master.LoadBalancer
- updateBalancerStatus(boolean) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupBasedLoadBalancer
- updateBlockCacheDeltaSizeHistogram(int) - Method in class org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManager
-
Update the increase/decrease blockcache size histogram
- updateBlockCacheDeltaSizeHistogram(int) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSource
-
Update the increase/decrease blockcache size histogram
- updateBlockCacheDeltaSizeHistogram(int) - Method in class org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSourceImpl
- updateBlockedFlushCount(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManager
-
Update/Set the blocked flush count histogram/gauge
- updateBlockedFlushCount(long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSource
-
Update/Set the blocked flush count histogram/gauge
- updateBlockedFlushCount(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSourceImpl
- updateBulkLoad(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
- updateCandidateFilesForRowKeyBefore(Iterator<HStoreFile>, KeyValue, Cell) - Method in interface org.apache.hadoop.hbase.regionserver.StoreFileManager
-
Updates the candidate list for finding row key before.
- updateCandidateFilesForRowKeyBefore(Iterator<HStoreFile>, KeyValue, Cell) - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
-
See
StoreFileManager.getCandidateFilesForRowKeyBefore(KeyValue)
andStoreFileManager.updateCandidateFilesForRowKeyBefore(Iterator, KeyValue, Cell)
for details on this methods. - updateCellsCountCompactedFromMob(long) - Method in class org.apache.hadoop.hbase.regionserver.HMobStore
- updateCellsCountCompactedToMob(long) - Method in class org.apache.hadoop.hbase.regionserver.HMobStore
- updateCellsSizeCompactedFromMob(long) - Method in class org.apache.hadoop.hbase.regionserver.HMobStore
- updateCellsSizeCompactedToMob(long) - Method in class org.apache.hadoop.hbase.regionserver.HMobStore
- updateCheckAndDelete(long) - Method in class org.apache.hadoop.hbase.regionserver.metrics.MetricsTableRequests
-
Update the CheckAndDelete time histogram.
- updateCheckAndDelete(long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
Update checkAndDelete histogram
- updateCheckAndDelete(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
- updateCheckAndDelete(HRegion, long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
- updateCheckAndMutate(long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsUserAggregate
- updateCheckAndMutate(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsUserAggregateImpl
- updateCheckAndMutate(long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsUserSource
- updateCheckAndMutate(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsUserSourceImpl
- updateCheckAndMutate(long, long) - Method in class org.apache.hadoop.hbase.regionserver.metrics.MetricsTableRequests
-
Update the CheckAndMutate time histogram.
- updateCheckAndMutate(long, long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
Update checkAndMutate histogram
- updateCheckAndMutate(long, long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
- updateCheckAndMutate(HRegion, long, long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
- updateCheckAndPut(long) - Method in class org.apache.hadoop.hbase.regionserver.metrics.MetricsTableRequests
-
Update the CheckAndPut time histogram.
- updateCheckAndPut(long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
Update checkAndPut histogram
- updateCheckAndPut(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
- updateCheckAndPut(HRegion, long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
- updateClusterMetrics(ClusterMetrics) - Method in interface org.apache.hadoop.hbase.master.LoadBalancer
-
Set the current cluster status.
- updateClusterMetrics(ClusterMetrics) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupBasedLoadBalancer
- updateCompactedMetrics(boolean, CompactionProgress) - Method in class org.apache.hadoop.hbase.regionserver.HStore
- updateCompaction(String, boolean, long, int, int, long, long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
- updateCompactionInputFileCount(boolean, long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
Update the compaction input number of files histogram
- updateCompactionInputFileCount(boolean, long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
- updateCompactionInputFileCount(boolean, long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableSource
-
Update the compaction input number of files histogram
- updateCompactionInputFileCount(boolean, long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableSourceImpl
- updateCompactionInputFileCount(String, boolean, long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTable
- updateCompactionInputSize(boolean, long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
Update the compaction total input file size histogram
- updateCompactionInputSize(boolean, long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
- updateCompactionInputSize(boolean, long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableSource
-
Update the compaction total input file size histogram
- updateCompactionInputSize(boolean, long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableSourceImpl
- updateCompactionInputSize(String, boolean, long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTable
- updateCompactionOutputFileCount(boolean, long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
Update the compaction output number of files histogram
- updateCompactionOutputFileCount(boolean, long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
- updateCompactionOutputFileCount(boolean, long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableSource
-
Update the compaction output number of files histogram
- updateCompactionOutputFileCount(boolean, long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableSourceImpl
- updateCompactionOutputFileCount(String, boolean, long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTable
- updateCompactionOutputSize(boolean, long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
Update the compaction total output file size
- updateCompactionOutputSize(boolean, long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
- updateCompactionOutputSize(boolean, long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableSource
-
Update the compaction total output file size
- updateCompactionOutputSize(boolean, long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableSourceImpl
- updateCompactionOutputSize(String, boolean, long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTable
- updateCompactionTime(boolean, long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
Update the compaction time histogram, both major and minor
- updateCompactionTime(boolean, long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
- updateCompactionTime(boolean, long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableSource
-
Update the compaction time histogram, both major and minor
- updateCompactionTime(boolean, long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableSourceImpl
- updateCompactionTime(String, boolean, long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTable
- updateConfiguration() - Method in interface org.apache.hadoop.hbase.client.Admin
-
Update the configuration and trigger an online config change on all the regionservers.
- updateConfiguration() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Update the configuration and trigger an online config change on all the masters and regionservers.
- updateConfiguration() - Method in class org.apache.hadoop.hbase.HBaseServerBase
-
Reload the configuration from disk.
- updateConfiguration(String) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Update the configuration and trigger an online config change on all the regionservers in the RSGroup.
- updateConfiguration(String) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Update the configuration and trigger an online config change on all the regionservers in the RSGroup.
- updateConfiguration(ServerName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Update the configuration and trigger an online config change on the regionserver.
- updateConfiguration(ServerName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Update the configuration and trigger an online config change on the regionserver.
- updateConfiguration(AdminProtos.UpdateConfigurationRequest) - Method in class org.apache.hadoop.hbase.client.AsyncRegionServerAdmin
- updateConfiguration(RpcController, AdminProtos.UpdateConfigurationRequest) - Method in class org.apache.hadoop.hbase.HBaseRpcServicesBase
- updateConfigurationForQuotasObserver(Configuration) - Method in class org.apache.hadoop.hbase.master.HMaster
-
Adds the
MasterQuotasObserver
to the list of configured Master observers to automatically remove quotas for a table when that table is deleted. - updateConnectAddr(String, String, String, InetSocketAddress) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
- updateConnectAddr(String, InetSocketAddress) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
- updateConnectionAccessTime() - Method in class org.apache.hadoop.hbase.util.ConnectionCache
-
Updates the access time for the current connection.
- updateCounters(ScanMetrics, long, Method, TaskAttemptContext, long) - Static method in class org.apache.hadoop.hbase.mapreduce.TableRecordReaderImpl
-
Deprecated.since 2.4.0 and 2.3.2, will be removed in 4.0.0 Use
TableRecordReaderImpl.updateCounters(ScanMetrics, long, TaskAttemptContext, long)
instead. - updateCounters(ScanMetrics, long, TaskAttemptContext, long) - Static method in class org.apache.hadoop.hbase.mapreduce.TableRecordReaderImpl
- updateCurrent() - Method in class org.apache.hadoop.hbase.regionserver.SegmentScanner
-
Private internal method for iterating over the segment, skipping the cells with irrelevant MVCC
- updateCurrentBlock(HFileBlock) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.EncodedScanner
-
Updates the current block to be the given
HFileBlock
. - updateCurrentBlock(HFileBlock) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
-
Updates the current block to be the given
HFileBlock
. - updateDeadServerOpenRegions(int) - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManager
- updateDeadServerOpenRegions(int) - Method in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
- updateDeadServerOpenRegions(int) - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManagerSourceImpl
- updateDelayInterval(long) - Method in class org.apache.hadoop.hbase.client.MetricsConnection.RunnerStats
- updateDelete() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegion
- updateDelete() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
-
Update related counts of deletes.
- updateDelete() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionSourceImpl
- updateDelete(long) - Method in class org.apache.hadoop.hbase.regionserver.metrics.MetricsTableRequests
-
Update the Delete time histogram
- updateDelete(long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
Update the Delete time histogram
- updateDelete(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
- updateDelete(long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsUserAggregate
- updateDelete(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsUserAggregateImpl
- updateDelete(long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsUserSource
- updateDelete(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsUserSourceImpl
- updateDelete(HRegion, long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
- updateDeleteBatch(long) - Method in class org.apache.hadoop.hbase.regionserver.metrics.MetricsTableRequests
-
Update the batch Delete time histogram
- updateDeleteBatch(long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
Update the Delete time histogram if a batch contains a delete op
- updateDeleteBatch(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
- updateDeleteBatch(HRegion, long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
- updateEmptyRegionInfoRegions(int) - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManager
- updateEstimateConsumeBatchQuota(int, int) - Method in class org.apache.hadoop.hbase.quotas.DefaultOperationQuota
-
Update estimate quota(read/write size/capacityUnits) which will be consumed
- updateEstimateConsumeScanQuota(ClientProtos.ScanRequest, long, long, long) - Method in class org.apache.hadoop.hbase.quotas.DefaultOperationQuota
-
Update estimate quota(read/write size/capacityUnits) which will be consumed
- updateExistingNodeData(ZKWatcher, String, byte[], int) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Deprecated.Unused
- updateFavoredNodes(Map<RegionInfo, List<ServerName>>) - Method in class org.apache.hadoop.hbase.favored.FavoredNodesManager
- updateFavoredNodes(AdminProtos.UpdateFavoredNodesRequest) - Method in class org.apache.hadoop.hbase.client.AsyncRegionServerAdmin
- updateFavoredNodes(RpcController, AdminProtos.UpdateFavoredNodesRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- updateFavoredNodes(RpcController, AdminProtos.UpdateFavoredNodesRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
- updateFavoredNodesMap(RegionInfo, List<ServerName>) - Method in class org.apache.hadoop.hbase.favored.FavoredNodesPlan
-
Update an assignment to the plan
- updateFilteredReadRequests() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsUserAggregate
- updateFilteredReadRequests() - Method in class org.apache.hadoop.hbase.regionserver.MetricsUserAggregateImpl
- updateFilteredRecords() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegion
- updateFlush(String, long, long, long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
- updateFlushMemstoreSize(long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableSource
-
Update the flush memstore size histogram
- updateFlushMemstoreSize(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableSourceImpl
- updateFlushMemstoreSize(String, long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTable
- updateFlushMemStoreSize(long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
Update the flush memstore size histogram
- updateFlushMemStoreSize(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
- updateFlushOutputSize(long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
Update the flush output file size histogram
- updateFlushOutputSize(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
- updateFlushOutputSize(long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableSource
-
Update the flush output file size histogram
- updateFlushOutputSize(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableSourceImpl
- updateFlushOutputSize(String, long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTable
- updateFlushTime(long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
Update the flush time histogram
- updateFlushTime(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
- updateFlushTime(long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableSource
-
Update the flush time histogram
- updateFlushTime(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableSourceImpl
- updateFlushTime(String, long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTable
- updateFsPreadTime(long) - Method in class org.apache.hadoop.hbase.io.MetricsIO
- updateFsPReadTime(long) - Method in interface org.apache.hadoop.hbase.io.MetricsIOSource
-
Update the fs positional read time histogram
- updateFsPReadTime(long) - Method in class org.apache.hadoop.hbase.io.MetricsIOSourceImpl
- updateFsReadTime(long) - Method in class org.apache.hadoop.hbase.io.MetricsIO
- updateFsReadTime(long) - Method in interface org.apache.hadoop.hbase.io.MetricsIOSource
-
Update the fs sequential read time histogram
- updateFsReadTime(long) - Method in class org.apache.hadoop.hbase.io.MetricsIOSourceImpl
- updateFsReadTime(long) - Method in interface org.apache.hadoop.hbase.ipc.RpcCall
- updateFsReadTime(long) - Method in class org.apache.hadoop.hbase.ipc.ServerCall
- updateFsWriteTime(long) - Method in class org.apache.hadoop.hbase.io.MetricsIO
- updateFsWriteTime(long) - Method in interface org.apache.hadoop.hbase.io.MetricsIOSource
-
Update the fs write time histogram
- updateFsWriteTime(long) - Method in class org.apache.hadoop.hbase.io.MetricsIOSourceImpl
- updateGet() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegion
- updateGet() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
-
Update related counts of gets
- updateGet() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionSourceImpl
- updateGet(long, long) - Method in class org.apache.hadoop.hbase.regionserver.metrics.MetricsTableRequests
-
Update the Get time histogram .
- updateGet(long, long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
Update the Get time histogram .
- updateGet(long, long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
- updateGet(long, long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsUserAggregate
- updateGet(long, long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsUserAggregateImpl
- updateGet(long, long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsUserSource
- updateGet(long, long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsUserSourceImpl
- updateGet(HRegion, long, long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
- updateHistogram(String, long) - Method in interface org.apache.hadoop.hbase.metrics.BaseSource
-
Add some value to a histogram.
- updateHistogram(String, long) - Method in class org.apache.hadoop.hbase.metrics.BaseSourceImpl
- updateHoles(int) - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManager
- updateInconsistentRegions(int) - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManager
- updateIncrement() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegion
- updateIncrement() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
-
Update related counts of increments.
- updateIncrement() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionSourceImpl
- updateIncrement(long, long) - Method in class org.apache.hadoop.hbase.regionserver.metrics.MetricsTableRequests
-
Update the Increment time histogram.
- updateIncrement(long, long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
Update the Increment time histogram.
- updateIncrement(long, long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
- updateIncrement(long, long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsUserAggregate
- updateIncrement(long, long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsUserAggregateImpl
- updateIncrement(long, long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsUserSource
- updateIncrement(long, long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsUserSourceImpl
- updateIncrement(HRegion, long, long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
- updateLatestBlockSizes(HFileContext, int, int) - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCompressedSizePredicator
-
Updates the predicator with both compressed and uncompressed sizes of latest block written.
- updateLatestBlockSizes(HFileContext, int, int) - Method in class org.apache.hadoop.hbase.io.hfile.PreviousBlockCompressionRatePredicator
-
Recalculates compression rate for the last block and adjusts the block size limit as: BLOCK_SIZE * (uncompressed/compressed).
- updateLatestBlockSizes(HFileContext, int, int) - Method in class org.apache.hadoop.hbase.io.hfile.UncompressedBlockSizePredicator
-
Empty implementation.
- updateLatestStamp(byte[]) - Method in class org.apache.hadoop.hbase.KeyValue
-
Update the timestamp.
- updateLatestStamp(Cell, byte[]) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
Sets the given timestamp to the cell iff current timestamp is
HConstants.LATEST_TIMESTAMP
. - updateLatestStamp(ExtendedCell, long) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
Sets the given timestamp to the cell iff current timestamp is
HConstants.LATEST_TIMESTAMP
. - updateLocation(HRegionLocation, boolean, boolean) - Method in class org.apache.hadoop.hbase.RegionLocations
-
Updates the location with new only if the new location has a higher seqNum than the old one or force is true.
- updateLowestUnflushedSequenceIdInWAL(boolean) - Method in class org.apache.hadoop.hbase.regionserver.AbstractMemStore
-
Updates the wal with the lowest sequence id (oldest entry) that is still in memory
- updateLowestUnflushedSequenceIdInWAL(boolean) - Method in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
- updateLowestUnflushedSequenceIdInWAL(boolean) - Method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore
- updateMax(AtomicLong, long) - Static method in class org.apache.hadoop.hbase.util.AtomicUtils
-
Updates a AtomicLong which is supposed to maintain the maximum values.
- updateMemStoreDeltaSizeHistogram(int) - Method in class org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManager
-
Update the increase/decrease memstore size histogram
- updateMemStoreDeltaSizeHistogram(int) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSource
-
Update the increase/decrease memstore size histogram
- updateMemStoreDeltaSizeHistogram(int) - Method in class org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSourceImpl
- updateMetaInfo(ExtendedCell, boolean, boolean, MemStoreSizing, boolean) - Method in class org.apache.hadoop.hbase.regionserver.CompositeImmutableSegment
- updateMetaInfo(ExtendedCell, boolean, boolean, MemStoreSizing, boolean) - Method in class org.apache.hadoop.hbase.regionserver.Segment
- updateMetaInfo(ExtendedCell, boolean, MemStoreSizing) - Method in class org.apache.hadoop.hbase.regionserver.Segment
- updateMetaParentRegions(Connection, List<RegionInfo>) - Method in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper.RestoreMetaChanges
- updateMetaWALSplitSize(long) - Method in interface org.apache.hadoop.hbase.master.MetricsMasterFileSystemSource
- updateMetaWALSplitSize(long) - Method in class org.apache.hadoop.hbase.master.MetricsMasterFilesystemSourceImpl
- updateMetaWALSplitTime(long) - Method in interface org.apache.hadoop.hbase.master.MetricsMasterFileSystemSource
- updateMetaWALSplitTime(long) - Method in class org.apache.hadoop.hbase.master.MetricsMasterFilesystemSourceImpl
- updateMetaWithFavoredNodesInfo(Map<RegionInfo, List<ServerName>>, Configuration) - Static method in class org.apache.hadoop.hbase.favored.FavoredNodeAssignmentHelper
-
Update meta table with favored nodes info
- updateMetaWithFavoredNodesInfo(Map<RegionInfo, List<ServerName>>, Connection) - Static method in class org.apache.hadoop.hbase.favored.FavoredNodeAssignmentHelper
-
Update meta table with favored nodes info
- updateMethodCountAndSizeByQueue(BlockingQueue<Runnable>, HashMap<String, Long>, HashMap<String, Long>) - Method in class org.apache.hadoop.hbase.ipc.FifoRpcScheduler
- updateMetrics(long, boolean) - Method in class org.apache.hadoop.hbase.util.JvmPauseMonitor
- updateMicros(long) - Method in interface org.apache.hadoop.hbase.metrics.Timer
-
Update the timer with the given duration in microseconds
- updateMillis(long) - Method in interface org.apache.hadoop.hbase.metrics.Timer
-
Update the timer with the given duration in milliseconds
- updateMin(AtomicLong, long) - Static method in class org.apache.hadoop.hbase.util.AtomicUtils
-
Updates a AtomicLong which is supposed to maintain the minimum values.
- updateMobFlushCount() - Method in class org.apache.hadoop.hbase.regionserver.HMobStore
- updateMobFlushedCellsCount(long) - Method in class org.apache.hadoop.hbase.regionserver.HMobStore
- updateMobFlushedCellsSize(long) - Method in class org.apache.hadoop.hbase.regionserver.HMobStore
- updateMobScanCellsCount(long) - Method in class org.apache.hadoop.hbase.regionserver.HMobStore
- updateMobScanCellsSize(long) - Method in class org.apache.hadoop.hbase.regionserver.HMobStore
- updateMostRecentTime(long) - Method in class org.apache.hadoop.hbase.util.ExponentialMovingAverage
- updateMostRecentTime(long) - Method in class org.apache.hadoop.hbase.util.MovingAverage
-
Update the most recent data.
- updateMostRecentTime(long) - Method in class org.apache.hadoop.hbase.util.SimpleMovingAverage
- updateMostRecentTime(long) - Method in class org.apache.hadoop.hbase.util.WindowMovingAverage
- updateNanos(long) - Method in interface org.apache.hadoop.hbase.metrics.Timer
-
Update the timer with the given duration in nanoseconds
- updateNumCurrentSpaceQuotaRegionSizeReports(long) - Method in interface org.apache.hadoop.hbase.master.MetricsMasterQuotaSource
-
Updates the metric tracking the number of region size reports the master is currently retaining in memory.
- updateNumCurrentSpaceQuotaRegionSizeReports(long) - Method in class org.apache.hadoop.hbase.master.MetricsMasterQuotaSourceImpl
- updateNumNamespacesInSpaceQuotaViolation(long) - Method in interface org.apache.hadoop.hbase.master.MetricsMasterQuotaSource
-
Updates the metric tracking the number of namespaces the master has computed to be in violation of their space quota.
- updateNumNamespacesInSpaceQuotaViolation(long) - Method in class org.apache.hadoop.hbase.master.MetricsMasterQuotaSourceImpl
- updateNumSpaceQuotas(long) - Method in interface org.apache.hadoop.hbase.master.MetricsMasterQuotaSource
-
Updates the metric tracking the number of space quotas defined in the system.
- updateNumSpaceQuotas(long) - Method in class org.apache.hadoop.hbase.master.MetricsMasterQuotaSourceImpl
- updateNumTablesInSpaceQuotaViolation(long) - Method in interface org.apache.hadoop.hbase.master.MetricsMasterQuotaSource
-
Updates the metric tracking the number of tables the master has computed to be in violation of their space quota.
- updateNumTablesInSpaceQuotaViolation(long) - Method in class org.apache.hadoop.hbase.master.MetricsMasterQuotaSourceImpl
- updateNumTablesInSpaceQuotaViolation(long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerQuotaSource
-
Updates the metric tracking how many tables this RegionServer has marked as in violation of their space quota.
- updateNumTablesInSpaceQuotaViolation(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerQuotaSourceImpl
- updateNumTableSpaceQuotaSnapshots(long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerQuotaSource
-
Updates the metric tracking how many tables this RegionServer has received
SpaceQuotaSnapshot
s for. - updateNumTableSpaceQuotaSnapshots(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerQuotaSourceImpl
- updateOldWALsDirSize() - Method in class org.apache.hadoop.hbase.master.MasterWalManager
- updateOrphanRegionsOnFs(int) - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManager
- updateOrphanRegionsOnRs(int) - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManager
- updateOverlaps(int) - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManager
- updatePageSize(int) - Method in class org.apache.hadoop.hbase.hbtop.screen.top.Paging
- updatePauseTimeWithGc(long) - Method in interface org.apache.hadoop.hbase.metrics.JvmPauseMonitorSource
-
Update the pause time histogram where GC activity was detected.
- updatePauseTimeWithGc(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
- updatePauseTimeWithGc(long) - Method in class org.apache.hadoop.hbase.rest.MetricsRESTSourceImpl
- updatePauseTimeWithGc(long) - Method in class org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceImpl
- updatePauseTimeWithoutGc(long) - Method in interface org.apache.hadoop.hbase.metrics.JvmPauseMonitorSource
-
Update the pause time histogram where GC activity was not detected.
- updatePauseTimeWithoutGc(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
- updatePauseTimeWithoutGc(long) - Method in class org.apache.hadoop.hbase.rest.MetricsRESTSourceImpl
- updatePauseTimeWithoutGc(long) - Method in class org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceImpl
- updatePeerConfig(String, ReplicationPeerConfig) - Method in class org.apache.hadoop.hbase.replication.FSReplicationPeerStorage
- updatePeerConfig(String, ReplicationPeerConfig) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeerStorage
-
Update the config a replication peer.
- updatePeerConfig(String, ReplicationPeerConfig) - Method in class org.apache.hadoop.hbase.replication.ZKReplicationPeerStorage
- updatePercent - Variable in class org.apache.hadoop.hbase.util.LoadTestTool
- updatePut() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegion
- updatePut() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
-
Update related counts of puts.
- updatePut() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionSourceImpl
- updatePut(long) - Method in class org.apache.hadoop.hbase.regionserver.metrics.MetricsTableRequests
-
Update the Put time histogram
- updatePut(long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
Update the Put time histogram
- updatePut(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
- updatePut(long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsUserAggregate
- updatePut(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsUserAggregateImpl
- updatePut(long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsUserSource
- updatePut(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsUserSourceImpl
- updatePut(HRegion, long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
- updatePutBatch(long) - Method in class org.apache.hadoop.hbase.regionserver.metrics.MetricsTableRequests
-
Update the batch Put time histogram
- updatePutBatch(long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
Update the PutBatch time histogram if a batch contains a Put op
- updatePutBatch(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
- updatePutBatch(HRegion, long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
- updateQuotaForRegionMerge(RegionInfo) - Method in class org.apache.hadoop.hbase.namespace.NamespaceAuditor
- updateQuotaSnapshot(Map<TableName, SpaceQuotaSnapshot>) - Method in class org.apache.hadoop.hbase.quotas.RegionServerSpaceQuotaManager
-
Updates the current
SpaceQuotaSnapshot
s for the RegionServer. - updateReaders(List<HStoreFile>, List<KeyValueScanner>) - Method in interface org.apache.hadoop.hbase.regionserver.ChangedReadersObserver
-
Notify observers.
- updateReaders(List<HStoreFile>, List<KeyValueScanner>) - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
- updateReadLatency(long, boolean, boolean) - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
- updateReadQueryMeter(HRegion, long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
- updateReadRequestCount() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegion
- updateReadRequestCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsUserAggregate
- updateReadRequestCount() - Method in class org.apache.hadoop.hbase.regionserver.MetricsUserAggregateImpl
- updateRecordsSize(int) - Method in class org.apache.hadoop.hbase.hbtop.screen.top.Paging
- updateRegionFavoredNodesMapping(String, List<HBaseProtos.ServerName>) - Method in class org.apache.hadoop.hbase.MockRegionServerServices
- updateRegionFavoredNodesMapping(String, List<HBaseProtos.ServerName>) - Method in interface org.apache.hadoop.hbase.regionserver.FavoredNodesForRegion
-
Used to update the favored nodes mapping when required.
- updateRegionFavoredNodesMapping(String, List<HBaseProtos.ServerName>) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
- updateRegionLocation(Connection, RegionInfo, ServerName, long, long) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Updates the location of the specified region in hbase:meta to be the specified server hostname and startcode.
- updateRegionState(Connection, RegionInfo, RegionState.State) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Update state column in hbase:meta.
- updateRegionStats(ServerName, byte[], RegionLoadStats) - Method in class org.apache.hadoop.hbase.client.MetricsConnection
- updateRegionStats(ServerName, byte[], RegionLoadStats) - Method in class org.apache.hadoop.hbase.client.ServerStatisticTracker
- updateRegionStats(ServerName, byte[], RegionLoadStats) - Method in interface org.apache.hadoop.hbase.client.StatisticTrackable
-
Update stats per region.
- updateReplay(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
- updateReplay(long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
Update the Replay time histogram.
- updateReplay(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
- updateReplay(long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsUserAggregate
- updateReplay(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsUserAggregateImpl
- updateReplay(long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsUserSource
- updateReplay(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsUserSourceImpl
- updateReplicationBasePeerConfigs(Configuration, ReplicationPeerConfig) - Static method in class org.apache.hadoop.hbase.client.replication.ReplicationPeerConfigUtil
-
Helper method to add/removev base peer configs from Configuration to ReplicationPeerConfig This merges the user supplied peer configuration
ReplicationPeerConfig
with peer configs provided as property hbase.replication.peer.base.configs in hbase configuration. - updateReplicationPeerConfig(String, ReplicationPeerConfig) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Update the peerConfig for the specified peer.
- updateReplicationPeerConfig(String, ReplicationPeerConfig) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Update the peerConfig for the specified peer
- updateReplicationPeerConfig(String, ReplicationPeerConfig) - Method in class org.apache.hadoop.hbase.master.HMaster
- updateReplicationPeerConfig(String, ReplicationPeerConfig) - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Update the peerConfig for the specified peer
- updateReplicationPeerConfig(RpcController, ReplicationProtos.UpdateReplicationPeerConfigRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- updateReplicationPeerConfigAsync(String, ReplicationPeerConfig) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Update the peerConfig for the specified peer but does not block and wait for it.
- updateRITCount(int) - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManager
-
set new value for number of regions in transition.
- updateRITCountOverThreshold(int) - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManager
-
update RIT count that are in this state for more than the threshold as defined by the property rit.metrics.threshold.time.
- updateRitDuration(long) - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManager
-
update the duration metrics of region is transition
- updateRitDuration(long) - Method in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
- updateRitDuration(long) - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManagerSourceImpl
- updateRITOldestAge(long) - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManager
-
update the timestamp for oldest region in transition metrics.
- updateRpc(MetricsConnection.CallStats) - Method in class org.apache.hadoop.hbase.client.MetricsConnection.CallTracker
- updateRpc(Descriptors.MethodDescriptor, TableName, Message, MetricsConnection.CallStats, Throwable) - Method in class org.apache.hadoop.hbase.client.MetricsConnection
-
Report RPC context to metrics system.
- updaters - Variable in class org.apache.hadoop.hbase.util.MultiThreadedUpdater
- updateRSGroupConfig(String, Map<String, String>) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Update RSGroup configuration
- updateRSGroupConfig(String, Map<String, String>) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Update RSGroup configuration
- updateRSGroupConfig(String, Map<String, String>) - Method in interface org.apache.hadoop.hbase.rsgroup.RSGroupInfoManager
-
Update RSGroup configuration
- updateRSGroupConfig(RpcController, RSGroupAdminProtos.UpdateRSGroupConfigRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- updaterThreads - Variable in class org.apache.hadoop.hbase.util.LoadTestTool
- UPDATES_BLOCKED_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- UPDATES_BLOCKED_TIME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- updateScan() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegion
- updateScan() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
-
Update related counts of resultScanner.next().
- updateScan() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionSourceImpl
- updateScan(long, long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsUserAggregate
- updateScan(long, long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsUserAggregateImpl
- updateScan(long, long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsUserSource
- updateScan(long, long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsUserSourceImpl
- updateScan(long, long, long) - Method in class org.apache.hadoop.hbase.regionserver.metrics.MetricsTableRequests
-
Update the scan metrics.
- updateScan(long, long, long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
Update the scan metrics.
- updateScan(long, long, long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
- updateScan(HRegion, long, long, long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
- updateServerStats(ServerName, byte[], Object) - Method in class org.apache.hadoop.hbase.client.MetricsConnection
- updateSnapshotCloneTime(long) - Method in interface org.apache.hadoop.hbase.master.MetricsSnapshotSource
- updateSnapshotCloneTime(long) - Method in class org.apache.hadoop.hbase.master.MetricsSnapshotSourceImpl
- updateSnapshotRestoreTime(long) - Method in interface org.apache.hadoop.hbase.master.MetricsSnapshotSource
- updateSnapshotRestoreTime(long) - Method in class org.apache.hadoop.hbase.master.MetricsSnapshotSourceImpl
- updateSnapshotTime(long) - Method in interface org.apache.hadoop.hbase.master.MetricsSnapshotSource
- updateSnapshotTime(long) - Method in class org.apache.hadoop.hbase.master.MetricsSnapshotSourceImpl
- updateSplitSize(long) - Method in interface org.apache.hadoop.hbase.master.MetricsMasterFileSystemSource
- updateSplitSize(long) - Method in class org.apache.hadoop.hbase.master.MetricsMasterFilesystemSourceImpl
- updateSplitTime(long) - Method in interface org.apache.hadoop.hbase.master.MetricsMasterFileSystemSource
- updateSplitTime(long) - Method in class org.apache.hadoop.hbase.master.MetricsMasterFilesystemSourceImpl
- updateSplitTime(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
- updateSplitTime(long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
Update the split transaction time histogram
- updateSplitTime(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
- updateSplitTime(long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableSource
-
Update the split transaction time histogram
- updateSplitTime(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableSourceImpl
- updateSplitTime(String, long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTable
- updateStats(StatisticTrackable, ServerName, byte[], RegionLoadStats) - Static method in class org.apache.hadoop.hbase.client.ResultStatsUtil
-
Update the statistics for the specified region.
- updateStats(Segment) - Method in class org.apache.hadoop.hbase.regionserver.AdaptiveMemStoreCompactionStrategy
- updateStats(Segment) - Method in class org.apache.hadoop.hbase.regionserver.MemStoreCompactionStrategy
- updateStatusWithMsg(String) - Method in class org.apache.hadoop.hbase.wal.BoundedRecoveredHFilesOutputSink
-
Set status message in
MonitoredTask
instance that is set in this OutputSink - updateStore(byte[], byte[], Long, boolean) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
updates the sequence number of a specific store.
- updateStore(byte[], byte[], Long, boolean) - Method in interface org.apache.hadoop.hbase.wal.WAL
-
updates the seuence number of a specific store.
- updateTableReadQueryMeter() - Method in class org.apache.hadoop.hbase.regionserver.metrics.MetricsTableRequests
-
Update table read QPS
- updateTableReadQueryMeter(long) - Method in class org.apache.hadoop.hbase.regionserver.metrics.MetricsTableRequests
-
Update table read QPS
- updateTableState(Connection, TableName, TableState.State) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Updates state in META Do not use.
- updateTableWriteQueryMeter() - Method in class org.apache.hadoop.hbase.regionserver.metrics.MetricsTableRequests
-
Update table write QPS
- updateTableWriteQueryMeter(long) - Method in class org.apache.hadoop.hbase.regionserver.metrics.MetricsTableRequests
-
Update table write QPS
- updateTunables(int, int, double) - Method in class org.apache.hadoop.hbase.ipc.AdaptiveLifoCoDelCallQueue
-
Update tunables.
- updateUnblockedFlushCount(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManager
-
Update/Set the unblocked flush count histogram/gauge
- updateUnblockedFlushCount(long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSource
-
Update/Set the unblocked flush count histogram/gauge
- updateUnblockedFlushCount(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSourceImpl
- updateUnknownServerOpenRegions(int) - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManager
- updateUnknownServerOpenRegions(int) - Method in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
- updateUnknownServerOpenRegions(int) - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManagerSourceImpl
- updateUnknownServerRegions(int) - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManager
- updateWithTrackerConfigs(Configuration, TableDescriptor) - Static method in class org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileTrackerFactory
- updateWithTrackerConfigs(TableDescriptorBuilder) - Method in interface org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileTracker
-
Adds StoreFileTracker implementations specific configurations into the table descriptor.
- updateWriteLatency(long) - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
- updateWriteQueryMeter(HRegion) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
- updateWriteQueryMeter(HRegion, long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
- upgrade(Set<ServerName>, Set<ServerName>, Set<ServerName>) - Method in class org.apache.hadoop.hbase.master.RegionServerTracker
-
Upgrade to active master mode, where besides tracking the changes of region server set, we will also started to add new region servers to ServerManager and also schedule SCP if a region server dies.
- upsert(Iterable<ExtendedCell>, long, MemStoreSizing) - Method in class org.apache.hadoop.hbase.regionserver.AbstractMemStore
- upsert(Iterable<ExtendedCell>, long, MemStoreSizing) - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
Adds or replaces the specified KeyValues.
- upsert(Iterable<ExtendedCell>, long, MemStoreSizing) - Method in interface org.apache.hadoop.hbase.regionserver.MemStore
-
Update or insert the specified cells.
- upsert(ExtendedCell, long, MemStoreSizing, boolean) - Method in class org.apache.hadoop.hbase.regionserver.MutableSegment
- usage() - Static method in class org.apache.hadoop.hbase.util.CompressionTest
- usage(String) - Static method in class org.apache.hadoop.hbase.mapreduce.ExportUtils
-
Common usage for other export tools.
- usage(String) - Method in class org.apache.hadoop.hbase.util.ServerCommandLine
-
Print usage information for this command line.
- USE_DEFAULT - Enum constant in enum class org.apache.hadoop.hbase.client.Durability
-
If this is for tables durability, use HBase's global default value (SYNC_WAL).
- USE_HTTP_CONF_KEY - Static variable in class org.apache.hadoop.hbase.thrift.Constants
- USE_META_CELL_COMPARATOR - Static variable in class org.apache.hadoop.hbase.regionserver.HRegion
-
Whether to use
MetaCellComparator
even if we are not meta region. - USE_META_REPLICAS - Static variable in class org.apache.hadoop.hbase.HConstants
-
Conf key for enabling meta replication
- USE_RESULT_SIZE_BYTES - Static variable in interface org.apache.hadoop.hbase.quotas.OperationQuota
-
If false, the default, then IO based throttles will consume read availability based on the block bytes scanned by the given request.
- USE_RESULT_SIZE_BYTES_DEFAULT - Static variable in interface org.apache.hadoop.hbase.quotas.OperationQuota
- USED_HEAP_SIZE - Enum constant in enum class org.apache.hadoop.hbase.hbtop.field.Field
- useEncodedScanner() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoder
-
Decides whether we should use a scanner over encoded blocks.
- useEncodedScanner() - Method in class org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoderImpl
- useEncodedScanner() - Method in class org.apache.hadoop.hbase.io.hfile.NoOpDataBlockEncoder
- useEncodedScanner(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoderImpl
- useExternalDfs(String) - Method in class org.apache.hadoop.hbase.testing.TestingHBaseClusterOption.Builder
- useExternalZooKeeper(String) - Method in class org.apache.hadoop.hbase.testing.TestingHBaseClusterOption.Builder
- useHsync - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
- USEMSLAB_DEFAULT - Static variable in interface org.apache.hadoop.hbase.regionserver.MemStoreLAB
- USEMSLAB_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MemStoreLAB
- user - Variable in class org.apache.hadoop.hbase.client.AsyncConnectionImpl
- user - Variable in class org.apache.hadoop.hbase.ipc.ServerCall
- org.apache.hadoop.hbase.security.User - Class in org.apache.hadoop.hbase.security
-
Wrapper to abstract out usage of user and group information in HBase.
- User() - Constructor for class org.apache.hadoop.hbase.security.User
- USER - Enum constant in enum class org.apache.hadoop.hbase.hbtop.field.Field
- USER - Enum constant in enum class org.apache.hadoop.hbase.hbtop.mode.Mode
- USER_COPROCESSORS_ENABLED_CONF_KEY - Static variable in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
- USER_COUNT - Enum constant in enum class org.apache.hadoop.hbase.hbtop.field.Field
- USER_REGION_COPROCESSOR_CONF_KEY - Static variable in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
- USER_SCAN - Enum constant in enum class org.apache.hadoop.hbase.regionserver.ScanType
- org.apache.hadoop.hbase.security.User.SecureHadoopUser - Class in org.apache.hadoop.hbase.security
-
Bridges
User
invocations to underlying calls toUserGroupInformation
for secure Hadoop 0.20 and versions 0.21 and above. - org.apache.hadoop.hbase.security.User.TestingGroups - Class in org.apache.hadoop.hbase.security
- useRetry() - Method in class org.apache.hadoop.hbase.util.RetryCounter
- userHasAdministratorAccess(ServletContext, String) - Static method in class org.apache.hadoop.hbase.http.HttpServer
-
Get the admin ACLs from the given ServletContext and check if the given user is in the ACL.
- userHasAdministratorAccess(AccessControlList, String) - Static method in class org.apache.hadoop.hbase.http.HttpServer
- UserMetrics - Interface in org.apache.hadoop.hbase
-
Encapsulates per-user load metrics.
- org.apache.hadoop.hbase.UserMetrics.ClientMetrics - Interface in org.apache.hadoop.hbase
- org.apache.hadoop.hbase.UserMetricsBuilder - Class in org.apache.hadoop.hbase
- org.apache.hadoop.hbase.UserMetricsBuilder.ClientMetricsImpl - Class in org.apache.hadoop.hbase
- org.apache.hadoop.hbase.hbtop.mode.UserModeStrategy - Class in org.apache.hadoop.hbase.hbtop.mode
-
Implementation for
ModeStrategy
for User Mode. - userProvider - Variable in class org.apache.hadoop.hbase.HBaseServerBase
- userProvider - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
- userProvider - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
- org.apache.hadoop.hbase.security.UserProvider - Class in org.apache.hadoop.hbase.security
-
Provide an instance of a user.
- UserProvider() - Constructor for class org.apache.hadoop.hbase.security.UserProvider
- org.apache.hadoop.hbase.quotas.UserQuotaState - Class in org.apache.hadoop.hbase.quotas
-
In-Memory state of the user quotas
- UserQuotaState() - Constructor for class org.apache.hadoop.hbase.quotas.UserQuotaState
- UserQuotaState(long) - Constructor for class org.apache.hadoop.hbase.quotas.UserQuotaState
- org.apache.hadoop.hbase.regionserver.querymatcher.UserScanQueryMatcher - Class in org.apache.hadoop.hbase.regionserver.querymatcher
-
Query matcher for user scan.
- UserScanQueryMatcher(Scan, ScanInfo, ColumnTracker, boolean, long, long) - Constructor for class org.apache.hadoop.hbase.regionserver.querymatcher.UserScanQueryMatcher
- UserTableDirFilter(FileSystem) - Constructor for class org.apache.hadoop.hbase.util.FSUtils.UserTableDirFilter
- useThisHostnameInstead - Variable in class org.apache.hadoop.hbase.HBaseServerBase
-
hostname specified by hostname config
- useUnsafeLayout() - Static method in class org.apache.hadoop.hbase.util.ClassSize
- utf8(byte[]) - Static method in class org.apache.hadoop.hbase.util.ClientUtils
-
Helper to translate byte[]s to UTF8 strings
- utf8(ByteBuffer) - Static method in class org.apache.hadoop.hbase.util.ClientUtils
-
Helper to translate a byte buffer to UTF8 strings
- UTF8 - Static variable in class org.apache.hadoop.hbase.util.OrderedBytes
- UTF8_CHARSET - Static variable in class org.apache.hadoop.hbase.HConstants
-
When we encode strings, we always specify UTF8 encoding
- UTF8_ENCODING - Static variable in class org.apache.hadoop.hbase.HConstants
-
When we encode strings, we always specify UTF8 encoding
V
- VALID_NAMESPACE_REGEX - Static variable in class org.apache.hadoop.hbase.TableName
- VALID_PORT_REGEX - Static variable in class org.apache.hadoop.hbase.util.Addressing
- VALID_TABLE_QUALIFIER_REGEX - Static variable in class org.apache.hadoop.hbase.TableName
- VALID_USER_TABLE_REGEX - Static variable in class org.apache.hadoop.hbase.TableName
- validate() - Method in class org.apache.hadoop.hbase.HBaseTestingUtility.SeenRowTracker
-
Deprecated.Validate that all the rows between startRow and stopRow are seen exactly once, and all other rows none
- validate(URI) - Static method in class org.apache.hadoop.hbase.client.ConnectionRegistryFactory
-
Check whether the given
uri
is valid. - validate(URI) - Method in interface org.apache.hadoop.hbase.client.ConnectionRegistryURIFactory
-
Validate the given
uri
. - validate(URI) - Method in class org.apache.hadoop.hbase.client.RpcConnectionRegistryURIFactory
- validate(URI) - Method in class org.apache.hadoop.hbase.client.ZKConnectionRegistryURIFactory
- validate(SnapshotProtos.SnapshotDescription, Configuration) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
Convert the passed snapshot description into a 'full' snapshot description based on default parameters, if none have been supplied.
- validateBlockAddition(Cacheable, Cacheable, BlockCacheKey) - Static method in class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil
-
Validate that the existing and newBlock are the same without including the nextBlockMetadata, if not, throw an exception.
- validateClasses(ClassLoader, String[], List<CoprocessorViolation>) - Method in class org.apache.hadoop.hbase.tool.coprocessor.CoprocessorValidator
- validateClasses(ClassLoader, List<String>, List<CoprocessorViolation>) - Method in class org.apache.hadoop.hbase.tool.coprocessor.CoprocessorValidator
- validateClusterKey(String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKConfig
-
Verifies that the given key matches the expected format for a ZooKeeper cluster key.
- validateInput(JobConf) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormat
- validatePreRestoreSnapshot(TableDescriptor, TableDescriptor, Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileTrackerValidationUtils
-
Makes sure restoring a snapshot does not break the current SFT setup follows StoreUtils.createStoreConfiguration
- validateRootPath(Path) - Static method in class org.apache.hadoop.hbase.util.CommonFSUtils
-
Verifies root directory path is a valid URI with a scheme
- validateStoreFile(Path) - Method in class org.apache.hadoop.hbase.regionserver.StoreEngine
-
Validates a store file by opening and closing it.
- validateStoreFileName(String) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
Validate the store file name.
- validateTableAndRegionCount(NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.master.TableNamespaceManager
- validateTables(ClassLoader, Admin, Pattern, List<CoprocessorViolation>) - Method in class org.apache.hadoop.hbase.tool.coprocessor.CoprocessorValidator
- validateWALFilename(String) - Static method in class org.apache.hadoop.hbase.wal.AbstractFSWALProvider
-
A WAL file name is of the format: <wal-name>
AbstractFSWALProvider.WAL_FILE_NAME_DELIMITER
<file-creation-timestamp>[.<suffix>]. - value - Variable in class org.apache.hadoop.hbase.ExtendedCellBuilderImpl
- value - Variable in class org.apache.hadoop.hbase.util.ManualEnvironmentEdge
- value() - Method in class org.apache.hadoop.hbase.client.Result
-
Returns the value of the first column in the Result.
- value() - Method in enum class org.apache.hadoop.hbase.replication.SyncReplicationState
- VALUE_MASK - Static variable in class org.apache.hadoop.hbase.util.ByteBufferUtils
- valueCompressionType - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractProtobufWALReader
- org.apache.hadoop.hbase.filter.ValueFilter - Class in org.apache.hadoop.hbase.filter
-
This filter is used to filter based on column value.
- ValueFilter(CompareOperator, ByteArrayComparable) - Constructor for class org.apache.hadoop.hbase.filter.ValueFilter
-
Constructor.
- valueOf(byte) - Static method in enum class org.apache.hadoop.hbase.security.AuthMethod
-
Return the object represented by the code.
- valueOf(byte[]) - Static method in class org.apache.hadoop.hbase.TableName
-
Construct a TableName
- valueOf(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.TableName
- valueOf(byte[], int, int) - Static method in class org.apache.hadoop.hbase.TableName
-
Construct a TableName
- valueOf(int) - Static method in enum class org.apache.hadoop.hbase.client.security.SecurityCapability
- valueOf(int) - Static method in enum class org.apache.hadoop.hbase.replication.SyncReplicationState
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.backup.BackupInfo.BackupPhase
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.backup.BackupInfo.BackupState
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.backup.BackupRestoreConstants.BackupCommand
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.backup.BackupType
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.CatalogReplicaMode
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.Cell.Type
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.CellBuilderType
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.client.CompactionState
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.client.CompactType
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.client.Consistency
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.client.Durability
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.client.IsolationLevel
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.client.LogQueryFilter.FilterByOperator
-
Deprecated.
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.client.LogQueryFilter.Type
-
Deprecated.
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.client.MasterSwitchType
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.client.MobCompactPartitionPolicy
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.client.RequestController.ReturnCode
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.client.Scan.ReadType
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.client.security.SecurityCapability
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.client.ServerType
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.client.SnapshotType
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.client.TableState.State
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.ClientMetaTableAccessor.QueryType
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.ClusterMetrics.Option
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.CompareOperator
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.CompatibilitySingletonFactory.SingletonStorage
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination.TaskFinisher.Status
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.coprocessor.RegionObserver.MutationType
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.Coprocessor.State
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.favored.FavoredNodesPlan.Position
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.filter.BitComparator.BitwiseOp
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.filter.Filter.ReturnCode
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.filter.FilterList.Operator
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.filter.FilterWrapper.FilterRowRetCode
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.filter.RegexStringComparator.EngineType
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.hbtop.field.Field
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.hbtop.field.FieldValueType
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.hbtop.mode.Mode
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.hbtop.terminal.Color
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.hbtop.terminal.KeyPress.Type
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.HConstants.OperationStatusCode
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.http.HttpConfig.Policy
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.io.compress.Compression.Algorithm
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.io.crypto.tls.KeyStoreFileType
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.io.crypto.tls.X509Util.ClientAuth
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.io.encoding.IndexBlockEncoding
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.io.FileChangeWatcher.State
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.io.hfile.BlockPriority
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.io.hfile.BlockType.BlockCategory
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.io.hfile.BlockType
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.io.hfile.ReaderContext.ReaderType
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.KeepDeletedCells
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.KeyValue.Type
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.mapreduce.SyncTable.SyncMapper.Counter
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.mapreduce.WALPlayer.Counter
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.master.RegionState.State
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.master.ServerManager.ServerLiveState
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.master.SplitLogManager.ResubmitDirective
-
Deprecated.
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.master.SplitLogManager.TerminationStatus
-
Deprecated.
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.MemoryCompactionPolicy
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.namequeues.NamedQueuePayload.NamedQueueEvent
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.PerformanceEvaluation.Counter
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.quotas.OperationQuota.OperationType
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.quotas.QuotaScope
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.quotas.QuotaType
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.quotas.RpcThrottlingException.Type
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.quotas.SpaceViolationPolicy
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.quotas.ThrottleType
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.regionserver.BloomType
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.regionserver.ChunkCreator.ChunkType
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.regionserver.CompactingMemStore.IndexType
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.regionserver.HRegion.FlushResult.Result
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.regionserver.MemStoreCompactionStrategy.Action
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceFactoryImpl.FactoryStorage
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.regionserver.querymatcher.DeleteTracker.DeleteResult
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher.MatchCode
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.regionserver.ReadPointCalculationLock.LockType
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.regionserver.Region.Operation
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.regionserver.ScannerContext.LimitScope
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.regionserver.ScannerContext.NextState
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.regionserver.ScanType
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.regionserver.SplitLogWorker.TaskExecutor.Status
-
Deprecated.
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileTrackerFactory.Trackers
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.regionserver.TimeRangeTracker.Type
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.regionserver.wal.CompressionContext.DictionaryIndex
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.regionserver.wal.WALActionsListener.RollRequestReason
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.regionserver.wal.WALEventTrackerListener.WalState
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.replication.ReplicationPeer.PeerState
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.replication.ReplicationPeerStorageType
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.replication.SyncReplicationState
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.ScanPerformanceEvaluation.ScanCounter
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.security.AuthMethod
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.security.SaslStatus
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.security.SaslUtil.QualityOfProtection
- valueOf(String) - Static method in class org.apache.hadoop.hbase.ServerName
-
Retrieve an instance of ServerName.
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.ServerTask.State
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.Size.Unit
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.snapshot.ExportSnapshot.ChecksumComparison
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.snapshot.ExportSnapshot.Counter
- valueOf(String) - Static method in class org.apache.hadoop.hbase.TableName
-
Construct a TableName
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.thrift.ImplType
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.thrift.ThriftMetrics.ThriftServerType
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.tool.coprocessor.CoprocessorViolation.Severity
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.util.ChecksumType
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.util.DNS.ServerType
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.util.HbckErrorReporter.ERROR_CODE
-
Deprecated.
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.util.IdReadWriteLockWithObjectPool.ReferenceType
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.util.Order
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.util.PoolMap.PoolType
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.util.PrettyPrinter.Unit
- valueOf(String) - Static method in enum class org.apache.hadoop.hbase.wal.WALTailingReader.State
- valueOf(String, int, long) - Static method in class org.apache.hadoop.hbase.ServerName
-
Retrieve an instance of ServerName.
- valueOf(String, long) - Static method in class org.apache.hadoop.hbase.ServerName
-
Retrieve an instance of ServerName.
- valueOf(String, String) - Static method in class org.apache.hadoop.hbase.TableName
- valueOf(String, PoolMap.PoolType) - Static method in enum class org.apache.hadoop.hbase.util.PoolMap.PoolType
- valueOf(String, PrettyPrinter.Unit) - Static method in class org.apache.hadoop.hbase.util.PrettyPrinter
-
Convert a human readable string to its value.
- valueOf(ByteBuffer) - Static method in class org.apache.hadoop.hbase.TableName
-
Construct a TableName
- valueOf(ByteBuffer, ByteBuffer) - Static method in class org.apache.hadoop.hbase.TableName
- valueOf(Address, long) - Static method in class org.apache.hadoop.hbase.ServerName
-
Retrieve an instance of
ServerName
. - values() - Static method in enum class org.apache.hadoop.hbase.backup.BackupInfo.BackupPhase
- values() - Static method in enum class org.apache.hadoop.hbase.backup.BackupInfo.BackupState
- values() - Static method in enum class org.apache.hadoop.hbase.backup.BackupRestoreConstants.BackupCommand
- values() - Static method in enum class org.apache.hadoop.hbase.backup.BackupType
- values() - Static method in enum class org.apache.hadoop.hbase.CatalogReplicaMode
- values() - Static method in enum class org.apache.hadoop.hbase.Cell.Type
- values() - Static method in enum class org.apache.hadoop.hbase.CellBuilderType
- values() - Static method in enum class org.apache.hadoop.hbase.client.CompactionState
- values() - Static method in enum class org.apache.hadoop.hbase.client.CompactType
- values() - Static method in enum class org.apache.hadoop.hbase.client.Consistency
- values() - Static method in enum class org.apache.hadoop.hbase.client.Durability
- values() - Static method in enum class org.apache.hadoop.hbase.client.IsolationLevel
- values() - Static method in enum class org.apache.hadoop.hbase.client.LogQueryFilter.FilterByOperator
-
Deprecated.
- values() - Static method in enum class org.apache.hadoop.hbase.client.LogQueryFilter.Type
-
Deprecated.
- values() - Static method in enum class org.apache.hadoop.hbase.client.MasterSwitchType
- values() - Static method in enum class org.apache.hadoop.hbase.client.MobCompactPartitionPolicy
- values() - Static method in enum class org.apache.hadoop.hbase.client.RequestController.ReturnCode
- values() - Static method in enum class org.apache.hadoop.hbase.client.Scan.ReadType
- values() - Static method in enum class org.apache.hadoop.hbase.client.security.SecurityCapability
- values() - Static method in enum class org.apache.hadoop.hbase.client.ServerType
- values() - Static method in enum class org.apache.hadoop.hbase.client.SnapshotType
- values() - Static method in enum class org.apache.hadoop.hbase.client.TableState.State
- values() - Static method in enum class org.apache.hadoop.hbase.ClientMetaTableAccessor.QueryType
- values() - Static method in enum class org.apache.hadoop.hbase.ClusterMetrics.Option
- values() - Static method in enum class org.apache.hadoop.hbase.CompareOperator
- values() - Static method in enum class org.apache.hadoop.hbase.CompatibilitySingletonFactory.SingletonStorage
- values() - Static method in enum class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination.TaskFinisher.Status
- values() - Static method in enum class org.apache.hadoop.hbase.coprocessor.RegionObserver.MutationType
- values() - Static method in enum class org.apache.hadoop.hbase.Coprocessor.State
- values() - Static method in enum class org.apache.hadoop.hbase.favored.FavoredNodesPlan.Position
- values() - Static method in enum class org.apache.hadoop.hbase.filter.BitComparator.BitwiseOp
- values() - Static method in enum class org.apache.hadoop.hbase.filter.Filter.ReturnCode
- values() - Static method in enum class org.apache.hadoop.hbase.filter.FilterList.Operator
- values() - Static method in enum class org.apache.hadoop.hbase.filter.FilterWrapper.FilterRowRetCode
- values() - Static method in enum class org.apache.hadoop.hbase.filter.RegexStringComparator.EngineType
- values() - Static method in enum class org.apache.hadoop.hbase.hbtop.field.Field
- values() - Static method in enum class org.apache.hadoop.hbase.hbtop.field.FieldValueType
- values() - Static method in enum class org.apache.hadoop.hbase.hbtop.mode.Mode
- values() - Method in class org.apache.hadoop.hbase.hbtop.Record
- values() - Static method in enum class org.apache.hadoop.hbase.hbtop.terminal.Color
- values() - Static method in enum class org.apache.hadoop.hbase.hbtop.terminal.KeyPress.Type
- values() - Static method in enum class org.apache.hadoop.hbase.HConstants.OperationStatusCode
- values() - Static method in enum class org.apache.hadoop.hbase.http.HttpConfig.Policy
- values() - Static method in enum class org.apache.hadoop.hbase.io.compress.Compression.Algorithm
- values() - Static method in enum class org.apache.hadoop.hbase.io.crypto.tls.KeyStoreFileType
- values() - Static method in enum class org.apache.hadoop.hbase.io.crypto.tls.X509Util.ClientAuth
- values() - Static method in enum class org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
- values() - Static method in enum class org.apache.hadoop.hbase.io.encoding.IndexBlockEncoding
- values() - Static method in enum class org.apache.hadoop.hbase.io.FileChangeWatcher.State
- values() - Static method in enum class org.apache.hadoop.hbase.io.hfile.BlockPriority
- values() - Static method in enum class org.apache.hadoop.hbase.io.hfile.BlockType.BlockCategory
- values() - Static method in enum class org.apache.hadoop.hbase.io.hfile.BlockType
- values() - Method in class org.apache.hadoop.hbase.io.hfile.HFileInfo
- values() - Static method in enum class org.apache.hadoop.hbase.io.hfile.ReaderContext.ReaderType
- values() - Static method in enum class org.apache.hadoop.hbase.KeepDeletedCells
- values() - Static method in enum class org.apache.hadoop.hbase.KeyValue.Type
- values() - Static method in enum class org.apache.hadoop.hbase.mapreduce.SyncTable.SyncMapper.Counter
- values() - Static method in enum class org.apache.hadoop.hbase.mapreduce.WALPlayer.Counter
- values() - Static method in enum class org.apache.hadoop.hbase.master.RegionState.State
- values() - Static method in enum class org.apache.hadoop.hbase.master.ServerManager.ServerLiveState
- values() - Static method in enum class org.apache.hadoop.hbase.master.SplitLogManager.ResubmitDirective
-
Deprecated.
- values() - Static method in enum class org.apache.hadoop.hbase.master.SplitLogManager.TerminationStatus
-
Deprecated.
- values() - Static method in enum class org.apache.hadoop.hbase.MemoryCompactionPolicy
- values() - Static method in enum class org.apache.hadoop.hbase.namequeues.NamedQueuePayload.NamedQueueEvent
- values() - Static method in enum class org.apache.hadoop.hbase.PerformanceEvaluation.Counter
- values() - Static method in enum class org.apache.hadoop.hbase.quotas.OperationQuota.OperationType
- values() - Static method in enum class org.apache.hadoop.hbase.quotas.QuotaScope
- values() - Static method in enum class org.apache.hadoop.hbase.quotas.QuotaType
- values() - Static method in enum class org.apache.hadoop.hbase.quotas.RpcThrottlingException.Type
- values() - Static method in enum class org.apache.hadoop.hbase.quotas.SpaceViolationPolicy
- values() - Static method in enum class org.apache.hadoop.hbase.quotas.ThrottleType
- values() - Static method in enum class org.apache.hadoop.hbase.regionserver.BloomType
- values() - Method in class org.apache.hadoop.hbase.regionserver.CellFlatMap
- values() - Static method in enum class org.apache.hadoop.hbase.regionserver.ChunkCreator.ChunkType
- values() - Static method in enum class org.apache.hadoop.hbase.regionserver.CompactingMemStore.IndexType
- values() - Static method in enum class org.apache.hadoop.hbase.regionserver.HRegion.FlushResult.Result
- values() - Static method in enum class org.apache.hadoop.hbase.regionserver.MemStoreCompactionStrategy.Action
- values() - Static method in enum class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceFactoryImpl.FactoryStorage
- values() - Static method in enum class org.apache.hadoop.hbase.regionserver.querymatcher.DeleteTracker.DeleteResult
- values() - Static method in enum class org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher.MatchCode
- values() - Static method in enum class org.apache.hadoop.hbase.regionserver.ReadPointCalculationLock.LockType
- values() - Static method in enum class org.apache.hadoop.hbase.regionserver.Region.Operation
- values() - Static method in enum class org.apache.hadoop.hbase.regionserver.ScannerContext.LimitScope
- values() - Static method in enum class org.apache.hadoop.hbase.regionserver.ScannerContext.NextState
- values() - Static method in enum class org.apache.hadoop.hbase.regionserver.ScanType
- values() - Static method in enum class org.apache.hadoop.hbase.regionserver.SplitLogWorker.TaskExecutor.Status
-
Deprecated.
- values() - Static method in enum class org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileTrackerFactory.Trackers
- values() - Static method in enum class org.apache.hadoop.hbase.regionserver.TimeRangeTracker.Type
- values() - Static method in enum class org.apache.hadoop.hbase.regionserver.wal.CompressionContext.DictionaryIndex
- values() - Static method in enum class org.apache.hadoop.hbase.regionserver.wal.WALActionsListener.RollRequestReason
- values() - Static method in enum class org.apache.hadoop.hbase.regionserver.wal.WALEventTrackerListener.WalState
- values() - Static method in enum class org.apache.hadoop.hbase.replication.ReplicationPeer.PeerState
- values() - Static method in enum class org.apache.hadoop.hbase.replication.ReplicationPeerStorageType
- values() - Static method in enum class org.apache.hadoop.hbase.replication.SyncReplicationState
- values() - Static method in enum class org.apache.hadoop.hbase.ScanPerformanceEvaluation.ScanCounter
- values() - Static method in enum class org.apache.hadoop.hbase.security.AuthMethod
- values() - Static method in enum class org.apache.hadoop.hbase.security.SaslStatus
- values() - Static method in enum class org.apache.hadoop.hbase.security.SaslUtil.QualityOfProtection
- values() - Static method in enum class org.apache.hadoop.hbase.ServerTask.State
- values() - Static method in enum class org.apache.hadoop.hbase.Size.Unit
- values() - Static method in enum class org.apache.hadoop.hbase.snapshot.ExportSnapshot.ChecksumComparison
- values() - Static method in enum class org.apache.hadoop.hbase.snapshot.ExportSnapshot.Counter
- values() - Static method in enum class org.apache.hadoop.hbase.thrift.ImplType
- values() - Static method in enum class org.apache.hadoop.hbase.thrift.ThriftMetrics.ThriftServerType
- values() - Static method in enum class org.apache.hadoop.hbase.tool.coprocessor.CoprocessorViolation.Severity
- values() - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
- values() - Static method in enum class org.apache.hadoop.hbase.util.ChecksumType
- values() - Static method in enum class org.apache.hadoop.hbase.util.DNS.ServerType
- values() - Static method in enum class org.apache.hadoop.hbase.util.HbckErrorReporter.ERROR_CODE
-
Deprecated.
- values() - Static method in enum class org.apache.hadoop.hbase.util.IdReadWriteLockWithObjectPool.ReferenceType
- values() - Static method in enum class org.apache.hadoop.hbase.util.Order
- values() - Method in interface org.apache.hadoop.hbase.util.PoolMap.Pool
- values() - Static method in enum class org.apache.hadoop.hbase.util.PoolMap.PoolType
- values() - Method in class org.apache.hadoop.hbase.util.PoolMap
- values() - Static method in enum class org.apache.hadoop.hbase.util.PrettyPrinter.Unit
- values() - Static method in enum class org.apache.hadoop.hbase.wal.WALTailingReader.State
- verbose - Variable in class org.apache.hadoop.hbase.util.MultiThreadedAction
- verify(byte[], byte[]...) - Static method in class org.apache.hadoop.hbase.util.LoadTestKVGenerator
-
Verifies that the given byte array is the same as what would be generated for the given seed strings (row/cf/column/...).
- verify(byte[], byte[], byte[], byte[]) - Method in class org.apache.hadoop.hbase.util.MultiThreadedAction.DefaultDataGenerator
- verify(byte[], byte[], Set<byte[]>) - Method in class org.apache.hadoop.hbase.util.MultiThreadedAction.DefaultDataGenerator
- VERIFY_BACKUP - Static variable in interface org.apache.hadoop.hbase.backup.BackupRestoreConstants
- verifyNumericRows(Table, byte[], int, int, int) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- verifyNumericRows(HRegion, byte[], int, int) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- verifyNumericRows(HRegion, byte[], int, int, boolean) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- verifyNumericRows(Region, byte[], int, int) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- verifyNumericRows(Region, byte[], int, int, boolean) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- verifyRegion(SnapshotProtos.SnapshotDescription, RegionInfo) - Method in class org.apache.hadoop.hbase.regionserver.RSSnapshotVerifier
- verifyRegionPlacement(boolean) - Method in class org.apache.hadoop.hbase.master.RegionPlacementMaintainer
-
Verify the region placement is consistent with the assignment plan
- verifyResultAgainstDataGenerator(Result, boolean) - Method in class org.apache.hadoop.hbase.util.MultiThreadedAction
-
See
MultiThreadedAction.verifyResultAgainstDataGenerator(Result, boolean, boolean)
. - verifyResultAgainstDataGenerator(Result, boolean, boolean) - Method in class org.apache.hadoop.hbase.util.MultiThreadedAction
-
Verifies the result from get or scan using the dataGenerator (that was presumably also used to generate said result).
- verifyResultsAndUpdateMetrics(boolean, Get[], long, Result[], Table, boolean) - Method in class org.apache.hadoop.hbase.util.MultiThreadedReader.HBaseReaderThread
- verifyResultsAndUpdateMetrics(boolean, Get, long, Result, Table, boolean) - Method in class org.apache.hadoop.hbase.util.MultiThreadedReader.HBaseReaderThread
- verifySnapshot(Configuration, FileSystem, Path, SnapshotProtos.SnapshotDescription) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotReferenceUtil
-
Verify the validity of the snapshot
- verifySnapshot(Configuration, FileSystem, SnapshotManifest) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotReferenceUtil
-
Verify the validity of the snapshot
- verifySnapshot(Configuration, FileSystem, SnapshotManifest, SnapshotReferenceUtil.StoreFileVisitor) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotReferenceUtil
-
Verify the validity of the snapshot.
- verifyStoreFile(Configuration, FileSystem, Path, SnapshotProtos.SnapshotDescription, RegionInfo, String, SnapshotProtos.SnapshotRegionManifest.StoreFile) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotReferenceUtil
-
Verify the validity of the snapshot store file
- verifyTableDescriptorIgnoreTableName(TableDescriptor, TableDescriptor) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- org.apache.hadoop.hbase.replication.VerifyWALEntriesReplicationEndpoint - Class in org.apache.hadoop.hbase.replication
-
A dummy
ReplicationEndpoint
that replicates nothing. - VerifyWALEntriesReplicationEndpoint() - Constructor for class org.apache.hadoop.hbase.replication.VerifyWALEntriesReplicationEndpoint
- VERSION - Static variable in interface org.apache.hadoop.hbase.Coprocessor
- VERSION - Static variable in class org.apache.hadoop.hbase.io.hfile.CompoundBloomFilterBase
-
The Bloom filter version.
- VERSION - Static variable in class org.apache.hadoop.hbase.regionserver.SecureBulkLoadManager
- VERSION_DELETED - Enum constant in enum class org.apache.hadoop.hbase.regionserver.querymatcher.DeleteTracker.DeleteResult
- VERSION_FILE_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
-
name of version file
- 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
- VERSION_MASKED - Enum constant in enum class org.apache.hadoop.hbase.regionserver.querymatcher.DeleteTracker.DeleteResult
- VERSION_STRING - Static variable in interface org.apache.hadoop.hbase.rest.Constants
- org.apache.hadoop.hbase.regionserver.VersionedSegmentsList - Class in org.apache.hadoop.hbase.regionserver
-
A list of segment managers coupled with the version of the memstore (version at the time it was created).
- VersionedSegmentsList(List<ImmutableSegment>, long) - Constructor for class org.apache.hadoop.hbase.regionserver.VersionedSegmentsList
- org.apache.hadoop.hbase.util.VersionInfo - Class in org.apache.hadoop.hbase.util
-
This class finds the Version information for HBase.
- VersionInfo() - Constructor for class org.apache.hadoop.hbase.util.VersionInfo
- org.apache.hadoop.hbase.client.VersionInfoUtil - Class in org.apache.hadoop.hbase.client
-
Class to help with parsing the version info.
- org.apache.hadoop.hbase.client.VersionInfoUtil.ServiceCallFunction<T1,
T2, R, E extends Throwable> - Interface in org.apache.hadoop.hbase.client -
We intend to use the local version for service call shortcut(s), so we use an interface compatible with a typical service call, with 2 args, return type, and an exception type.
- versionNumberToString(int) - Static method in class org.apache.hadoop.hbase.client.VersionInfoUtil
-
Returns the passed-in
version
int as a version String (e.g. - org.apache.hadoop.hbase.rest.VersionResource - Class in org.apache.hadoop.hbase.rest
-
Implements REST software version reporting
- VersionResource() - Constructor for class org.apache.hadoop.hbase.rest.VersionResource
-
Constructor
- VERSIONS - Static variable in class org.apache.hadoop.hbase.HConstants
- vintToBytes(long) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Encode a long value as a variable length integer.
- VISIBILITY_EXP_RESOLVER_CLASS - Static variable in class org.apache.hadoop.hbase.mapreduce.CellCreator
- VISIBILITY_EXP_SERIALIZATION_FORMAT_TAG_TYPE - Static variable in class org.apache.hadoop.hbase.TagType
- VISIBILITY_TAG_TYPE - Static variable in class org.apache.hadoop.hbase.TagType
- org.apache.hadoop.hbase.mapreduce.VisibilityExpressionResolver - Interface in org.apache.hadoop.hbase.mapreduce
-
Interface to convert visibility expressions into Tags for storing along with Cells in HFiles.
- visit(Result) - Method in interface org.apache.hadoop.hbase.ClientMetaTableAccessor.Visitor
-
Visit the catalog table row.
- visit(HDFSBlocksDistribution.HostAndWeight) - Method in interface org.apache.hadoop.hbase.HDFSBlocksDistribution.Visitor
- visit(TNode, AvlUtil.AvlNodeVisitor<TNode>) - Static method in class org.apache.hadoop.hbase.util.AvlUtil.AvlTree
-
Visit each node of the tree
- visitLogEntryBeforeWrite(RegionInfo, WALKey, WALEdit) - Method in interface org.apache.hadoop.hbase.regionserver.wal.WALActionsListener
-
Called before each write.
- visitNamespaceQuotas(String, QuotaProtos.Quotas) - Method in interface org.apache.hadoop.hbase.quotas.QuotaTableUtil.NamespaceQuotasVisitor
- visitNode(TNode) - Method in interface org.apache.hadoop.hbase.util.AvlUtil.AvlNodeVisitor
-
Visitor
- visitReferencedFiles(Configuration, FileSystem, Path, SnapshotProtos.SnapshotDescription, SnapshotReferenceUtil.SnapshotVisitor) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotReferenceUtil
-
Iterate over the snapshot store files, restored.edits and logs
- visitReferencedFiles(Configuration, FileSystem, Path, SnapshotReferenceUtil.SnapshotVisitor) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotReferenceUtil
-
Iterate over the snapshot store files
- visitRegionServerQuotas(String, QuotaProtos.Quotas) - Method in interface org.apache.hadoop.hbase.quotas.QuotaTableUtil.QuotasVisitor
- visitRegionStoreFiles(FileSystem, Path, FSVisitor.StoreFileVisitor) - Static method in class org.apache.hadoop.hbase.util.FSVisitor
-
Iterate over the region store files
- visitRegionStoreFiles(SnapshotProtos.SnapshotRegionManifest, SnapshotReferenceUtil.StoreFileVisitor) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotReferenceUtil
-
Iterate over the snapshot store files in the specified region
- visitTableQuotas(TableName, QuotaProtos.Quotas) - Method in interface org.apache.hadoop.hbase.quotas.QuotaTableUtil.TableQuotasVisitor
- visitTableStoreFiles(FileSystem, Path, FSVisitor.StoreFileVisitor) - Static method in class org.apache.hadoop.hbase.util.FSVisitor
-
Iterate over the table store files
- visitUserQuotas(String, String, QuotaProtos.Quotas) - Method in interface org.apache.hadoop.hbase.quotas.QuotaTableUtil.UserQuotasVisitor
- visitUserQuotas(String, QuotaProtos.Quotas) - Method in interface org.apache.hadoop.hbase.quotas.QuotaTableUtil.UserQuotasVisitor
- visitUserQuotas(String, TableName, QuotaProtos.Quotas) - Method in interface org.apache.hadoop.hbase.quotas.QuotaTableUtil.UserQuotasVisitor
- vLength - Variable in class org.apache.hadoop.hbase.ExtendedCellBuilderImpl
- vOffset - Variable in class org.apache.hadoop.hbase.ExtendedCellBuilderImpl
W
- W - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
ASCII code for 'W'
- WAIT_ON_REGIONSERVERS_INTERVAL - Static variable in class org.apache.hadoop.hbase.master.ServerManager
- WAIT_ON_REGIONSERVERS_MAXTOSTART - Static variable in class org.apache.hadoop.hbase.master.ServerManager
- WAIT_ON_REGIONSERVERS_MINTOSTART - Static variable in class org.apache.hadoop.hbase.master.ServerManager
- WAIT_ON_REGIONSERVERS_TIMEOUT - Static variable in class org.apache.hadoop.hbase.master.ServerManager
- waitFor(long, long, boolean, <any>) - Method in class org.apache.hadoop.hbase.HBaseCommonTestingUtility
-
Deprecated.Wrapper method for
Waiter#waitFor(Configuration, long, long, boolean, Predicate)
. - waitFor(long, long, <any>) - Method in class org.apache.hadoop.hbase.HBaseCommonTestingUtility
-
Deprecated.Wrapper method for
Waiter#waitFor(Configuration, long, long, Predicate)
. - waitFor(long, <any>) - Method in class org.apache.hadoop.hbase.HBaseCommonTestingUtility
-
Deprecated.Wrapper method for
Waiter#waitFor(Configuration, long, Predicate)
. - waitForActiveAndReadyMaster() - Method in class org.apache.hadoop.hbase.HBaseCluster
-
Deprecated.Blocks until there is an active master and that master has completed initialization.
- waitForActiveAndReadyMaster(long) - Method in class org.apache.hadoop.hbase.HBaseCluster
-
Deprecated.Blocks until there is an active master and that master has completed initialization.
- waitForActiveAndReadyMaster(long) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.Blocks until there is an active master and that master has completed initialization.
- waitForBaseZNode(Configuration) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Waits for HBase installation's base (parent) znode to become available.
- waitForCacheInitialization(long) - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCache
-
Wait for the block cache implementation to be completely enabled.
- waitForCacheInitialization(long) - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
- waitForDatanodesRegistered(int) - Method in class org.apache.hadoop.hbase.HBaseCluster
-
Deprecated.
- waitForDataNodeToStart(ServerName, long) - Method in class org.apache.hadoop.hbase.HBaseCluster
-
Deprecated.Wait for the specified datanode to join the cluster
- waitForDataNodeToStart(ServerName, long) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.
- waitForDataNodeToStop(ServerName, long) - Method in class org.apache.hadoop.hbase.HBaseCluster
-
Deprecated.Wait for the specified datanode to stop the thread / process.
- waitForDataNodeToStop(ServerName, long) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.
- waitForFinish() - Method in class org.apache.hadoop.hbase.util.MultiThreadedAction
- waitForFinish() - Method in class org.apache.hadoop.hbase.util.MultiThreadedUpdater
- waitForFinish() - Method in class org.apache.hadoop.hbase.util.MultiThreadedWriter
- waitForFlushes() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Wait for all current flushes of the region to complete
- waitForFlushes(long) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
- waitForFlushes(long) - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Wait for all current flushes of the region to complete
- waitForFlushesAndCompactions() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Wait for all current flushes and compactions of the region to complete
- waitForFreeSlot(long, int, Consumer<Long>) - Method in interface org.apache.hadoop.hbase.client.RequestController
-
Wait until there is at least one slot for a new task.
- waitForHostPort(String, int) - Static method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- waitForMasterToStop(ServerName, long) - Method in class org.apache.hadoop.hbase.HBaseCluster
-
Deprecated.Wait for the specified master to stop the thread / process.
- waitForMasterToStop(ServerName, long) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.
- waitForMaximumCurrentTasks(long, long, int, Consumer<Long>) - Method in interface org.apache.hadoop.hbase.client.RequestController
-
Waits for the running tasks to complete.
- waitForMetaOnline() - Method in class org.apache.hadoop.hbase.master.HMaster
-
Check hbase:meta is up and ready for reading.
- waitForNamenodeAvailable() - Method in class org.apache.hadoop.hbase.HBaseCluster
-
Deprecated.Wait for the namenode.
- waitForNameNodeToStart(ServerName, long) - Method in class org.apache.hadoop.hbase.HBaseCluster
-
Deprecated.Wait for the specified namenode to join the cluster
- waitForNameNodeToStart(ServerName, long) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.
- waitForNameNodeToStop(ServerName, long) - Method in class org.apache.hadoop.hbase.HBaseCluster
-
Deprecated.Wait for the specified namenode to stop
- waitForNameNodeToStop(ServerName, long) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.
- waitForRegionServers(MonitoredTask) - Method in class org.apache.hadoop.hbase.master.ServerManager
-
Wait for the region servers to report in.
- waitForRegionServerToStart(String, int, long) - Method in class org.apache.hadoop.hbase.HBaseCluster
-
Deprecated.Wait for the specified region server to join the cluster
- waitForRegionServerToStop(ServerName, long) - Method in class org.apache.hadoop.hbase.HBaseCluster
-
Deprecated.Wait for the specified region server to stop the thread / process.
- waitForRegionServerToStop(ServerName, long) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.
- waitForSafePoint() - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
- waitForServerOnline() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
- waitForServerOnline() - Method in class org.apache.hadoop.hbase.util.JVMClusterUtil.RegionServerThread
-
Block until the region server has come online, indicating it is ready to be used.
- waitForUpdates() - Method in class org.apache.hadoop.hbase.regionserver.Segment
- waitForWaiters(long, int) - Method in class org.apache.hadoop.hbase.util.IdLock
- waitForWaiters(T, int) - Method in class org.apache.hadoop.hbase.util.IdReadWriteLock
- waitForZkNodeToStart(ServerName, long) - Method in class org.apache.hadoop.hbase.HBaseCluster
-
Deprecated.Wait for the specified zookeeper node to join the cluster
- waitForZkNodeToStart(ServerName, long) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.
- waitForZkNodeToStop(ServerName, long) - Method in class org.apache.hadoop.hbase.HBaseCluster
-
Deprecated.Wait for the specified zookeeper node to stop the thread / process.
- waitForZkNodeToStop(ServerName, long) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.
- waiting() - Method in interface org.apache.hadoop.hbase.master.ServerListener
-
Started waiting on RegionServers to check-in.
- WAITING - Enum constant in enum class org.apache.hadoop.hbase.ServerTask.State
- waitInterval() - Method in class org.apache.hadoop.hbase.quotas.RateLimiter
-
Returns estimate of the ms required to wait before being able to provide 1 resource.
- waitInterval(long) - Method in class org.apache.hadoop.hbase.quotas.RateLimiter
-
Returns estimate of the ms required to wait before being able to provide "amount" resources.
- waitLabelAvailable(long, String...) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Wait until labels is ready in VisibilityLabelsCache.
- waitMetaRegionLocation(ZKWatcher, long) - Static method in class org.apache.hadoop.hbase.zookeeper.MetaTableLocator
-
Gets the meta region location, if available, and waits for up to the specified timeout if not immediately available.
- waitOnMaster(int) - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
Wait for the specified master to stop.
- waitOnMaster(int) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.Wait for the specified master to stop.
- waitOnMaster(JVMClusterUtil.MasterThread) - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
Wait for the specified master to stop.
- waitOnRegionServer(int) - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
Wait for the specified region server to stop.
- waitOnRegionServer(int) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.Wait for the specified region server to stop.
- waitOnRegionServer(JVMClusterUtil.RegionServerThread) - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
Wait for the specified region server to stop.
- waitOnSafeMode(Configuration, long) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
If DFS, check safe mode and if so, wait until we clear it.
- waitTableAvailable(byte[], long) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Wait until all regions in a table have been assigned
- waitTableAvailable(TableName) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Wait until all regions in a table have been assigned.
- waitTableAvailable(TableName, long) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- waitTableDisabled(byte[]) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Waits for a table to be 'disabled'.
- waitTableDisabled(byte[], long) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Waits for a table to be 'disabled'.
- waitTableDisabled(TableName, long) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- waitTableEnabled(byte[], long) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Waits for a table to be 'enabled'.
- waitTableEnabled(TableName) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Waits for a table to be 'enabled'.
- waitTableEnabled(TableName, long) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.
- waitToBecomeLeader() - Method in class org.apache.hadoop.hbase.zookeeper.ZKLeaderManager
-
Deprecated.Blocks until this instance has claimed the leader ZNode in ZooKeeper
- waitUntilAllRegionsAssigned(TableName) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Wait until all regions for a table in hbase:meta have a non-empty info:server, up to a configuable timeout value (default is 60 seconds) This means all regions have been deployed, master has been informed and updated hbase:meta with the regions deployed server.
- waitUntilAllRegionsAssigned(TableName, long) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Wait until all regions for a table in hbase:meta have a non-empty info:server, or until timeout.
- waitUntilAllSystemRegionsAssigned() - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Waith until all system table's regions get assigned
- waitUntilAssigned(Admin, RegionInfo) - Static method in class org.apache.hadoop.hbase.util.HBaseFsckRepair
- waitUntilNoRegionsInTransition() - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Wait until no regions in transition.
- waitUntilNoRegionsInTransition(long) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Deprecated.Wait until no regions in transition.
- waitUntilShutDown() - Method in class org.apache.hadoop.hbase.HBaseCluster
-
Deprecated.Wait for HBase Cluster to shut down.
- waitUntilShutDown() - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Deprecated.
- waitUntilStopped() - Method in class org.apache.hadoop.hbase.regionserver.regionreplication.RegionReplicationSink
-
Make sure that we have finished all the replicating requests.
- waitUntilWalRollFinished() - Method in class org.apache.hadoop.hbase.wal.AbstractWALRoller
-
Wait until all wals have been rolled after calling
AbstractWALRoller.requestRollAll()
. - wake(MasterProcedureScheduler) - Method in class org.apache.hadoop.hbase.master.WorkerAssigner
- WAKE_FREQ - Static variable in class org.apache.hadoop.hbase.ExecutorStatusChore
- wal - Variable in class org.apache.hadoop.hbase.wal.AbstractFSWALProvider
- org.apache.hadoop.hbase.wal.WAL - Interface in org.apache.hadoop.hbase.wal
-
A Write Ahead Log (WAL) provides service for reading, writing waledits.
- WAL_AVOID_LOCAL_WRITES_DEFAULT - Static variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
- WAL_AVOID_LOCAL_WRITES_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
- WAL_BATCH_SIZE - Static variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
- WAL_BLOCK_SIZE - Static variable in class org.apache.hadoop.hbase.regionserver.wal.WALUtil
- WAL_CELL_CODEC_CLASS_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.wal.WALCellCodec
-
Configuration key for the class to use when encoding cells in the WAL
- WAL_COPROCESSOR_CONF_KEY - Static variable in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
- WAL_DURABILITY - Static variable in class org.apache.hadoop.hbase.mapreduce.Import
- WAL_ENABLED - Static variable in class org.apache.hadoop.hbase.wal.WALFactory
- WAL_EVENT_TRACKER - Enum constant in enum class org.apache.hadoop.hbase.namequeues.NamedQueuePayload.NamedQueueEvent
- WAL_EVENT_TRACKER_TABLE_NAME - Static variable in class org.apache.hadoop.hbase.namequeues.WALEventTrackerTableAccessor
-
WALEventTrackerTableAccessor.WAL_EVENT_TRACKER_TABLE_NAME_STR
table name - can be enabled with config - hbase.regionserver.wal.event.tracker.enabled - WAL_EVENT_TRACKER_TABLE_NAME_STR - Static variable in class org.apache.hadoop.hbase.namequeues.WALEventTrackerTableAccessor
- WAL_EXCLUDE_DATANODE_TTL_KEY - Static variable in class org.apache.hadoop.hbase.io.asyncfs.monitor.ExcludeDatanodeManager
-
Configure for the TTL time of the datanodes excluded
- WAL_FILE_NAME_DELIMITER - Static variable in class org.apache.hadoop.hbase.wal.AbstractFSWALProvider
- WAL_FILE_NAME_DELIMITER - Static variable in class org.apache.hadoop.hbase.wal.AbstractWALProvider
- WAL_HSYNC_CONF_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.HRegion
- WAL_LENGTH_COLUMN - Static variable in class org.apache.hadoop.hbase.namequeues.WALEventTrackerTableAccessor
- WAL_MAX_EXCLUDE_SLOW_DATANODE_COUNT_KEY - Static variable in class org.apache.hadoop.hbase.io.asyncfs.monitor.ExcludeDatanodeManager
-
Configure for the max count the excluded datanodes.
- WAL_NAME_COLUMN - Static variable in class org.apache.hadoop.hbase.namequeues.WALEventTrackerTableAccessor
- WAL_OFF - Static variable in class org.apache.hadoop.hbase.mapreduce.MultiTableOutputFormat
-
Property value to disable write-ahead logging
- WAL_OFF - Static variable in class org.apache.hadoop.hbase.mapreduce.TableOutputFormat
-
Property value to disable write-ahead logging
- WAL_ON - Static variable in class org.apache.hadoop.hbase.mapreduce.MultiTableOutputFormat
-
Property value to use write-ahead logging
- WAL_ON - Static variable in class org.apache.hadoop.hbase.mapreduce.TableOutputFormat
-
Property value to use write-ahead logging
- WAL_PROPERTY - Static variable in class org.apache.hadoop.hbase.mapreduce.MultiTableOutputFormat
-
Set this to
MultiTableOutputFormat.WAL_OFF
to turn off write-ahead logging (WAL) - WAL_PROPERTY - Static variable in class org.apache.hadoop.hbase.mapreduce.TableOutputFormat
-
Set this to
TableOutputFormat.WAL_OFF
to turn off write-ahead logging (WAL) - WAL_PROVIDER - Static variable in class org.apache.hadoop.hbase.wal.WALFactory
- WAL_ROLL_MULTIPLIER - Static variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
- WAL_ROLL_PERIOD_KEY - Static variable in class org.apache.hadoop.hbase.wal.AbstractWALRoller
- WAL_ROLL_RETRIES - Static variable in class org.apache.hadoop.hbase.wal.AbstractWALRoller
-
Configure for the max count of log rolling retry.
- WAL_ROLL_WAIT_TIMEOUT - Static variable in class org.apache.hadoop.hbase.wal.AbstractWALRoller
-
Configure for the timeout of log rolling retry.
- WAL_SHUTDOWN_WAIT_TIMEOUT_MS - Static variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
- WAL_SPLIT_TO_HFILE - Static variable in class org.apache.hadoop.hbase.wal.WALSplitter
-
Split WAL directly to hfiles instead of into intermediary 'recovered.edits' files.
- WAL_STATE_COLUMN - Static variable in class org.apache.hadoop.hbase.namequeues.WALEventTrackerTableAccessor
- WAL_STORAGE_POLICY - Static variable in class org.apache.hadoop.hbase.HConstants
-
Configuration name of WAL storage policy Valid values are: HOT, COLD, WARM, ALL_SSD, ONE_SSD, LAZY_PERSIST See http://hadoop.apache.org/docs/r2.7.3/hadoop-project-dist/hadoop-hdfs/ArchivalStorage.html
- WAL_STREAM_READER_CLASS_IMPL - Static variable in class org.apache.hadoop.hbase.wal.WALFactory
-
Used in tests for injecting customized stream reader implementation, for example, inject fault when reading, etc.
- WAL_SYNC_TIMEOUT_MS - Static variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
- WAL_VALUE_COMPRESSION_TYPE - Static variable in class org.apache.hadoop.hbase.regionserver.wal.CompressionContext
- org.apache.hadoop.hbase.wal.WAL.Entry - Class in org.apache.hadoop.hbase.wal
-
Utility class that lets us keep track of the edit with it's key.
- org.apache.hadoop.hbase.regionserver.wal.WALActionsListener - Interface in org.apache.hadoop.hbase.regionserver.wal
-
Get notification of WAL events.
- org.apache.hadoop.hbase.regionserver.wal.WALActionsListener.RollRequestReason - Enum Class in org.apache.hadoop.hbase.regionserver.wal
-
The reason for the log roll request.
- walArchiveDir - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
dir path where old logs are kept.
- org.apache.hadoop.hbase.regionserver.wal.WALCellCodec - Class in org.apache.hadoop.hbase.regionserver.wal
-
Compression in this class is lifted off Compressor/KeyValueCompression.
- WALCellCodec() - Constructor for class org.apache.hadoop.hbase.regionserver.wal.WALCellCodec
-
All subclasses must implement a no argument constructor
- WALCellCodec(Configuration, CompressionContext) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.WALCellCodec
-
Default constructor - all subclasses must implement a constructor with this signature if they are to be dynamically loaded from the
Configuration
. - org.apache.hadoop.hbase.regionserver.wal.WALCellCodec.ByteStringCompressor - Interface in org.apache.hadoop.hbase.regionserver.wal
- org.apache.hadoop.hbase.regionserver.wal.WALCellCodec.ByteStringUncompressor - Interface in org.apache.hadoop.hbase.regionserver.wal
- org.apache.hadoop.hbase.regionserver.wal.WALCellCodec.EnsureKvEncoder - Class in org.apache.hadoop.hbase.regionserver.wal
- org.apache.hadoop.hbase.replication.WALCellFilter - Interface in org.apache.hadoop.hbase.replication
-
A filter for WAL entry cells before being sent over to replication.
- org.apache.hadoop.hbase.regionserver.wal.WALClosedException - Exception in org.apache.hadoop.hbase.regionserver.wal
-
Thrown when
LogRoller
try to roll writer but the WAL already was closed. - WALClosedException() - Constructor for exception org.apache.hadoop.hbase.regionserver.wal.WALClosedException
- WALClosedException(String) - Constructor for exception org.apache.hadoop.hbase.regionserver.wal.WALClosedException
- org.apache.hadoop.hbase.coprocessor.WALCoprocessor - Interface in org.apache.hadoop.hbase.coprocessor
-
WALCoprocessor don't support loading services using
Coprocessor.getServices()
. - org.apache.hadoop.hbase.coprocessor.WALCoprocessorEnvironment - Interface in org.apache.hadoop.hbase.coprocessor
- org.apache.hadoop.hbase.regionserver.wal.WALCoprocessorHost - Class in org.apache.hadoop.hbase.regionserver.wal
-
Implements the coprocessor environment and runtime support for coprocessors loaded within a
WAL
. - WALCoprocessorHost(WAL, Configuration) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.WALCoprocessorHost
-
Constructor
- walDir - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
WAL directory, where all WAL files would be placed.
- org.apache.hadoop.hbase.wal.WALEdit - Class in org.apache.hadoop.hbase.wal
-
Used in HBase's transaction log (WAL) to represent a collection of edits (Cell/KeyValue objects) that came in as a single transaction.
- WALEdit() - Constructor for class org.apache.hadoop.hbase.wal.WALEdit
- WALEdit(boolean) - Constructor for class org.apache.hadoop.hbase.wal.WALEdit
-
Deprecated.since 2.0.1 and will be removed in 4.0.0. Use
WALEdit(int, boolean)
instead. - WALEdit(int) - Constructor for class org.apache.hadoop.hbase.wal.WALEdit
-
Deprecated.since 2.0.1 and will be removed in 4.0.0. Use
WALEdit(int, boolean)
instead. - WALEdit(int, boolean) - Constructor for class org.apache.hadoop.hbase.wal.WALEdit
- WALEdit(WALEdit) - Constructor for class org.apache.hadoop.hbase.wal.WALEdit
-
Create a new WALEdit from a existing
WALEdit
. - org.apache.hadoop.hbase.wal.WALEditInternalHelper - Class in org.apache.hadoop.hbase.wal
-
A helper class so we can call some package private methods of
WALEdit
from other packages. - WALEDITS - Enum constant in enum class org.apache.hadoop.hbase.mapreduce.WALPlayer.Counter
- walEditsStopOffset - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractProtobufWALReader
- org.apache.hadoop.hbase.replication.WALEntryFilter - Interface in org.apache.hadoop.hbase.replication
-
A Filter for WAL entries before being sent over to replication.
- org.apache.hadoop.hbase.regionserver.wal.WALEventTrackerListener - Class in org.apache.hadoop.hbase.regionserver.wal
- WALEventTrackerListener(Configuration, NamedQueueRecorder, ServerName) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.WALEventTrackerListener
- org.apache.hadoop.hbase.regionserver.wal.WALEventTrackerListener.WalState - Enum Class in org.apache.hadoop.hbase.regionserver.wal
- org.apache.hadoop.hbase.namequeues.WALEventTrackerPayload - Class in org.apache.hadoop.hbase.namequeues
- WALEventTrackerPayload(String, String, long, String, long) - Constructor for class org.apache.hadoop.hbase.namequeues.WALEventTrackerPayload
- org.apache.hadoop.hbase.namequeues.WALEventTrackerQueueService - Class in org.apache.hadoop.hbase.namequeues
- WALEventTrackerQueueService(Configuration) - Constructor for class org.apache.hadoop.hbase.namequeues.WALEventTrackerQueueService
- WALEventTrackerQueueService(Configuration, MetricsWALEventTrackerSource) - Constructor for class org.apache.hadoop.hbase.namequeues.WALEventTrackerQueueService
- org.apache.hadoop.hbase.namequeues.WALEventTrackerTableAccessor - Class in org.apache.hadoop.hbase.namequeues
- org.apache.hadoop.hbase.wal.WALFactory - Class in org.apache.hadoop.hbase.wal
-
Entry point for users of the Write Ahead Log.
- WALFactory(Configuration, String) - Constructor for class org.apache.hadoop.hbase.wal.WALFactory
-
Create a WALFactory.
- WALFactory(Configuration, ServerName, Abortable) - Constructor for class org.apache.hadoop.hbase.wal.WALFactory
-
Create a WALFactory.
- WALFILE_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- WALFILE_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- WALFILE_SIZE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- WALFILE_SIZE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- walFile2Props - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
Map of WAL log file to properties.
- walFilePrefix - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
Prefix of a WAL file, usually the region server name it is hosted on.
- walFileSuffix - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
Suffix included on generated wal file names
- walFs - Variable in class org.apache.hadoop.hbase.HBaseServerBase
- walFS - Variable in class org.apache.hadoop.hbase.wal.WALSplitter
- org.apache.hadoop.hbase.regionserver.wal.WALHeaderEOFException - Exception in org.apache.hadoop.hbase.regionserver.wal
-
A special EOFException to indicate that the EOF happens when we read the header of a WAL file.
- WALHeaderEOFException() - Constructor for exception org.apache.hadoop.hbase.regionserver.wal.WALHeaderEOFException
- WALHeaderEOFException(String) - Constructor for exception org.apache.hadoop.hbase.regionserver.wal.WALHeaderEOFException
- WALHeaderEOFException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.regionserver.wal.WALHeaderEOFException
- org.apache.hadoop.hbase.mapreduce.WALInputFormat - Class in org.apache.hadoop.hbase.mapreduce
-
Simple
InputFormat
forWAL
files. - WALInputFormat() - Constructor for class org.apache.hadoop.hbase.mapreduce.WALInputFormat
- org.apache.hadoop.hbase.wal.WALKey - Interface in org.apache.hadoop.hbase.wal
-
Key for WAL Entry.
- org.apache.hadoop.hbase.wal.WALKeyImpl - Class in org.apache.hadoop.hbase.wal
-
Default implementation of Key for an Entry in the WAL.
- WALKeyImpl() - Constructor for class org.apache.hadoop.hbase.wal.WALKeyImpl
- WALKeyImpl(byte[], TableName, long) - Constructor for class org.apache.hadoop.hbase.wal.WALKeyImpl
- WALKeyImpl(byte[], TableName, long, long, long, MultiVersionConcurrencyControl) - Constructor for class org.apache.hadoop.hbase.wal.WALKeyImpl
-
Create the log key for writing to somewhere.
- WALKeyImpl(byte[], TableName, long, long, List<UUID>, long, long, MultiVersionConcurrencyControl) - Constructor for class org.apache.hadoop.hbase.wal.WALKeyImpl
-
Create the log key for writing to somewhere.
- WALKeyImpl(byte[], TableName, long, long, List<UUID>, long, long, MultiVersionConcurrencyControl, NavigableMap<byte[], Integer>) - Constructor for class org.apache.hadoop.hbase.wal.WALKeyImpl
-
Create the log key for writing to somewhere.
- WALKeyImpl(byte[], TableName, long, long, UUID) - Constructor for class org.apache.hadoop.hbase.wal.WALKeyImpl
- WALKeyImpl(byte[], TableName, long, long, UUID, MultiVersionConcurrencyControl) - Constructor for class org.apache.hadoop.hbase.wal.WALKeyImpl
- WALKeyImpl(byte[], TableName, long, List<UUID>, long, long, MultiVersionConcurrencyControl) - Constructor for class org.apache.hadoop.hbase.wal.WALKeyImpl
-
Create the log key for writing to somewhere.
- WALKeyImpl(byte[], TableName, long, List<UUID>, long, long, MultiVersionConcurrencyControl, NavigableMap<byte[], Integer>) - Constructor for class org.apache.hadoop.hbase.wal.WALKeyImpl
-
Create the log key for writing to somewhere.
- WALKeyImpl(byte[], TableName, long, List<UUID>, long, long, MultiVersionConcurrencyControl, NavigableMap<byte[], Integer>, Map<String, byte[]>) - Constructor for class org.apache.hadoop.hbase.wal.WALKeyImpl
- WALKeyImpl(byte[], TableName, long, NavigableMap<byte[], Integer>) - Constructor for class org.apache.hadoop.hbase.wal.WALKeyImpl
- WALKeyImpl(byte[], TableName, long, MultiVersionConcurrencyControl) - Constructor for class org.apache.hadoop.hbase.wal.WALKeyImpl
- WALKeyImpl(byte[], TableName, long, MultiVersionConcurrencyControl, NavigableMap<byte[], Integer>) - Constructor for class org.apache.hadoop.hbase.wal.WALKeyImpl
- WALKeyImpl(byte[], TableName, long, MultiVersionConcurrencyControl, NavigableMap<byte[], Integer>, Map<String, byte[]>) - Constructor for class org.apache.hadoop.hbase.wal.WALKeyImpl
- WALKeyImpl(NavigableMap<byte[], Integer>) - Constructor for class org.apache.hadoop.hbase.wal.WALKeyImpl
- WALKeyImpl(WALKeyImpl, Map<String, byte[]>) - Constructor for class org.apache.hadoop.hbase.wal.WALKeyImpl
-
Copy constructor that takes in an existing WALKeyImpl plus some extended attributes.
- WALKeyImpl(WALKey, List<UUID>, MultiVersionConcurrencyControl, NavigableMap<byte[], Integer>, Map<String, byte[]>) - Constructor for class org.apache.hadoop.hbase.wal.WALKeyImpl
-
Copy constructor that takes in an existing WALKey, the extra WALKeyImpl fields that the parent interface is missing, plus some extended attributes.
- org.apache.hadoop.hbase.io.WALLink - Class in org.apache.hadoop.hbase.io
-
WALLink describes a link to a WAL.
- WALLink(Configuration, String, String) - Constructor for class org.apache.hadoop.hbase.io.WALLink
- WALLink(Path, String, String) - Constructor for class org.apache.hadoop.hbase.io.WALLink
- WALLink(Path, Path) - Constructor for class org.apache.hadoop.hbase.io.WALLink
- WALMapper() - Constructor for class org.apache.hadoop.hbase.mapreduce.WALPlayer.WALMapper
- org.apache.hadoop.hbase.coprocessor.WALObserver - Interface in org.apache.hadoop.hbase.coprocessor
-
It's provided to have a way for coprocessors to observe, rewrite, or skip WALEdits as they are being written to the WAL.
- org.apache.hadoop.hbase.wal.WALPerformanceEvaluation - Class in org.apache.hadoop.hbase.wal
-
This class runs performance benchmarks for
WAL
. - WALPerformanceEvaluation() - Constructor for class org.apache.hadoop.hbase.wal.WALPerformanceEvaluation
- org.apache.hadoop.hbase.util.WALPerformanceEvaluationUtil - Class in org.apache.hadoop.hbase.util
-
This class contains code copied from HBaseTestingUtil and its super classes required by WALPerformanceEvaluation.
- WALPerformanceEvaluationUtil(Configuration) - Constructor for class org.apache.hadoop.hbase.util.WALPerformanceEvaluationUtil
- org.apache.hadoop.hbase.mapreduce.WALPlayer - Class in org.apache.hadoop.hbase.mapreduce
-
A tool to replay WAL files as a M/R job.
- WALPlayer() - Constructor for class org.apache.hadoop.hbase.mapreduce.WALPlayer
- WALPlayer(Configuration) - Constructor for class org.apache.hadoop.hbase.mapreduce.WALPlayer
- org.apache.hadoop.hbase.mapreduce.WALPlayer.Counter - Enum Class in org.apache.hadoop.hbase.mapreduce
-
Enum for map metrics.
- org.apache.hadoop.hbase.mapreduce.WALPlayer.WALMapper - Class in org.apache.hadoop.hbase.mapreduce
-
A mapper that writes out
Mutation
to be directly applied to a running HBase instance. - org.apache.hadoop.hbase.wal.WALPrettyPrinter - Class in org.apache.hadoop.hbase.wal
-
WALPrettyPrinter prints the contents of a given WAL with a variety of options affecting formatting and extent of content.
- WALPrettyPrinter() - Constructor for class org.apache.hadoop.hbase.wal.WALPrettyPrinter
-
Basic constructor that simply initializes values to reasonable defaults.
- org.apache.hadoop.hbase.wal.WALProvider - Interface in org.apache.hadoop.hbase.wal
-
The Write Ahead Log (WAL) stores all durable edits to the HRegion.
- org.apache.hadoop.hbase.wal.WALProvider.AsyncWriter - Interface in org.apache.hadoop.hbase.wal
- org.apache.hadoop.hbase.wal.WALProvider.Writer - Interface in org.apache.hadoop.hbase.wal
- org.apache.hadoop.hbase.wal.WALProvider.WriterBase - Interface in org.apache.hadoop.hbase.wal
- walRollFinished() - Method in class org.apache.hadoop.hbase.wal.AbstractWALRoller
-
Returns true if all WAL roll finished
- walRollRequestFinished() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
For testing
- walRootDir - Variable in class org.apache.hadoop.hbase.HBaseServerBase
- walRootDir - Variable in class org.apache.hadoop.hbase.wal.WALSplitter
- wals - Variable in class org.apache.hadoop.hbase.wal.AbstractWALRoller
- walShutdownTimeout - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
- org.apache.hadoop.hbase.wal.WALSplitter - Class in org.apache.hadoop.hbase.wal
-
Split RegionServer WAL files.
- org.apache.hadoop.hbase.wal.WALSplitter.PipelineController - Class in org.apache.hadoop.hbase.wal
-
Contains some methods to control WAL-entries producer / consumer interactions
- org.apache.hadoop.hbase.wal.WALSplitUtil - Class in org.apache.hadoop.hbase.wal
-
This class provides static methods to support WAL splitting related works
- org.apache.hadoop.hbase.wal.WALSplitUtil.MutationReplay - Class in org.apache.hadoop.hbase.wal
-
A struct used by getMutationsFromWALEntry
- WALStartTimeComparator() - Constructor for class org.apache.hadoop.hbase.wal.AbstractFSWALProvider.WALStartTimeComparator
- org.apache.hadoop.hbase.wal.WALStreamReader - Interface in org.apache.hadoop.hbase.wal
-
A one way WAL reader, without reset and seek support.
- org.apache.hadoop.hbase.regionserver.wal.WALSyncTimeoutIOException - Exception in org.apache.hadoop.hbase.regionserver.wal
-
Thrown when
WAL.sync()
timeout. - WALSyncTimeoutIOException() - Constructor for exception org.apache.hadoop.hbase.regionserver.wal.WALSyncTimeoutIOException
- WALSyncTimeoutIOException(String) - Constructor for exception org.apache.hadoop.hbase.regionserver.wal.WALSyncTimeoutIOException
- WALSyncTimeoutIOException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.regionserver.wal.WALSyncTimeoutIOException
- WALSyncTimeoutIOException(Throwable) - Constructor for exception org.apache.hadoop.hbase.regionserver.wal.WALSyncTimeoutIOException
- org.apache.hadoop.hbase.wal.WALTailingReader - Interface in org.apache.hadoop.hbase.wal
-
A WAL reader which is designed for be able to tailing the WAL file which is currently being written.
- org.apache.hadoop.hbase.wal.WALTailingReader.Result - Class in org.apache.hadoop.hbase.wal
- org.apache.hadoop.hbase.wal.WALTailingReader.State - Enum Class in org.apache.hadoop.hbase.wal
- org.apache.hadoop.hbase.regionserver.wal.WALUtil - Class in org.apache.hadoop.hbase.regionserver.wal
-
Helper methods to ease Region Server integration with the Write Ahead Log (WAL).
- WANT - Enum constant in enum class org.apache.hadoop.hbase.io.crypto.tls.X509Util.ClientAuth
- WARMUP_BEFORE_MOVE - Static variable in class org.apache.hadoop.hbase.master.HMaster
- warmupHRegion(RegionInfo, TableDescriptor, WAL, Configuration, RegionServerServices, CancelableProgressable) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
- warmupRegion(AdminProtos.WarmupRegionRequest) - Method in class org.apache.hadoop.hbase.client.AsyncRegionServerAdmin
- warmupRegion(RpcController, AdminProtos.AdminService.BlockingInterface, RegionInfo) - Static method in class org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
-
A helper to warmup a region given a region name using admin protocol
- warmupRegion(RpcController, AdminProtos.WarmupRegionRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
- warmupRegion(RpcController, AdminProtos.WarmupRegionRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
Warmup a region on this server.
- WARN_RESPONSE_SIZE - Static variable in class org.apache.hadoop.hbase.ipc.RpcServer
- WARN_RESPONSE_TIME - Static variable in class org.apache.hadoop.hbase.ipc.RpcServer
- WARN_SCAN_RESPONSE_SIZE - Static variable in class org.apache.hadoop.hbase.ipc.RpcServer
- WARN_SCAN_RESPONSE_TIME - Static variable in class org.apache.hadoop.hbase.ipc.RpcServer
- WARN_THRESHOLD_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.metrics.JvmPauseMonitorSource
- WARN_THRESHOLD_COUNT_KEY - Static variable in interface org.apache.hadoop.hbase.metrics.JvmPauseMonitorSource
- WARN_THRESHOLD_KEY - Static variable in class org.apache.hadoop.hbase.util.JvmPauseMonitor
- WARNING - Enum constant in enum class org.apache.hadoop.hbase.tool.coprocessor.CoprocessorViolation.Severity
- warnResponseSize - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
- warnResponseTime - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
- warnScanResponseSize - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
- warnScanResponseTime - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
- wasOperationAttemptedByServer() - Method in exception org.apache.hadoop.hbase.exceptions.PreemptiveFastFailException
-
Deprecated.Returns true if operation was attempted by server, false otherwise.
- watchAndCheckExists(ZKWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Watch the specified znode for delete/create/change events.
- watcher - Variable in class org.apache.hadoop.hbase.coordination.ZkCoordinatedStateManager
-
Deprecated.
- watcher - Variable in class org.apache.hadoop.hbase.zookeeper.ZKListener
- WEAK - Enum constant in enum class org.apache.hadoop.hbase.util.IdReadWriteLockWithObjectPool.ReferenceType
- org.apache.hadoop.hbase.util.WeakObjectPool<K,
V> - Class in org.apache.hadoop.hbase.util -
A
WeakReference
based shared object pool. - WeakObjectPool(ObjectPool.ObjectFactory<K, V>) - Constructor for class org.apache.hadoop.hbase.util.WeakObjectPool
- WeakObjectPool(ObjectPool.ObjectFactory<K, V>, int) - Constructor for class org.apache.hadoop.hbase.util.WeakObjectPool
- WeakObjectPool(ObjectPool.ObjectFactory<K, V>, int, int) - Constructor for class org.apache.hadoop.hbase.util.WeakObjectPool
- webAppContext - Variable in class org.apache.hadoop.hbase.http.HttpServer
- webServer - Variable in class org.apache.hadoop.hbase.http.HttpServer
- WEEKLY - Enum constant in enum class org.apache.hadoop.hbase.client.MobCompactPartitionPolicy
-
Compact mob files within one calendar week into one file
- WeightComparator() - Constructor for class org.apache.hadoop.hbase.HDFSBlocksDistribution.HostAndWeight.WeightComparator
- org.apache.hadoop.hbase.util.WeightedMovingAverage<T> - Class in org.apache.hadoop.hbase.util
-
Different from SMA
SimpleMovingAverage
, WeightedMovingAverage gives each data different weight. - WeightedMovingAverage(String) - Constructor for class org.apache.hadoop.hbase.util.WeightedMovingAverage
- WeightedMovingAverage(String, int) - Constructor for class org.apache.hadoop.hbase.util.WeightedMovingAverage
- WHEEL_TIMER - Static variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
- WHILE_ARRAY - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
WHILE Array
- WHILE_BUFFER - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
- org.apache.hadoop.hbase.filter.WhileMatchFilter - Class in org.apache.hadoop.hbase.filter
-
A wrapper filter that returns true from
WhileMatchFilter.filterAllRemaining()
as soon as the wrapped filtersFilter.filterRowKey(Cell)
,Filter.filterCell(org.apache.hadoop.hbase.Cell)
,Filter.filterRow()
orFilter.filterAllRemaining()
methods returns true. - WhileMatchFilter(Filter) - Constructor for class org.apache.hadoop.hbase.filter.WhileMatchFilter
- WHITE - Enum constant in enum class org.apache.hadoop.hbase.hbtop.terminal.Color
- WHITESPACE - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
ASCII code for whitespace
- org.apache.hadoop.hbase.util.WindowMovingAverage<T> - Class in org.apache.hadoop.hbase.util
-
Instead of calculate a whole time average, this class focus on the last N.
- WindowMovingAverage(String) - Constructor for class org.apache.hadoop.hbase.util.WindowMovingAverage
- WindowMovingAverage(String, int) - Constructor for class org.apache.hadoop.hbase.util.WindowMovingAverage
- WINDOWS - Static variable in class org.apache.hadoop.hbase.util.FSUtils
-
Set to true on Windows platforms
- withBackupId(String) - Method in class org.apache.hadoop.hbase.backup.RestoreRequest.Builder
- withBackupRootDir(String) - Method in class org.apache.hadoop.hbase.backup.RestoreRequest.Builder
- withBackupSetName(String) - Method in class org.apache.hadoop.hbase.backup.BackupRequest.Builder
- withBackupType(BackupType) - Method in class org.apache.hadoop.hbase.backup.BackupRequest.Builder
- withBandwidthPerTasks(int) - Method in class org.apache.hadoop.hbase.backup.BackupRequest.Builder
- withBlockSize(int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileContextBuilder
- withBlockSize(int) - Method in class org.apache.hadoop.hbase.regionserver.StoreContext.Builder
- withBlockType(BlockType) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockBuilder
- withBloomType(BloomType) - Method in class org.apache.hadoop.hbase.regionserver.StoreContext.Builder
- withBloomType(BloomType) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileWriter.Builder
- withByteBuff(ByteBuff) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockBuilder
- withByteBuffAllocator(ByteBuffAllocator) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockBuilder
- withBytesPerCheckSum(int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileContextBuilder
- withCacheConfig(CacheConfig) - Method in class org.apache.hadoop.hbase.regionserver.StoreContext.Builder
- withCellComparator(CellComparator) - Method in class org.apache.hadoop.hbase.io.hfile.HFileContextBuilder
- withCellComparator(CellComparator) - Method in class org.apache.hadoop.hbase.regionserver.StoreContext.Builder
- withCellComparator(CellComparator) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileWriter.Builder
- withCheck(boolean) - Method in class org.apache.hadoop.hbase.backup.RestoreRequest.Builder
- withChecksumType(ChecksumType) - Method in class org.apache.hadoop.hbase.io.hfile.HFileContextBuilder
- withColumnFamily(byte[]) - Method in class org.apache.hadoop.hbase.io.hfile.HFileContextBuilder
- withColumnFamilyDescriptor(ColumnFamilyDescriptor) - Method in class org.apache.hadoop.hbase.regionserver.StoreContext.Builder
- withCompactedFilesSupplier(Supplier<Collection<HStoreFile>>) - Method in class org.apache.hadoop.hbase.regionserver.StoreContext.Builder
- withCompactedFilesSupplier(Supplier<Collection<HStoreFile>>) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileWriter.Builder
- withCompression(Compression.Algorithm) - Method in class org.apache.hadoop.hbase.io.hfile.HFileContextBuilder
- withCompressTags(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileContextBuilder
- withCreateTime(long) - Method in class org.apache.hadoop.hbase.io.hfile.HFileContextBuilder
- withDataBlockEncoding(DataBlockEncoding) - Method in class org.apache.hadoop.hbase.io.hfile.HFileContextBuilder
- withEncryptionContext(Encryption.Context) - Method in class org.apache.hadoop.hbase.io.hfile.HFileContextBuilder
- withEncryptionContext(Encryption.Context) - Method in class org.apache.hadoop.hbase.regionserver.StoreContext.Builder
- withEvictedBlocks(long) - Method in class org.apache.hadoop.hbase.CacheEvictionStatsBuilder
- withFamilyStoreDirectoryPath(Path) - Method in class org.apache.hadoop.hbase.regionserver.StoreContext.Builder
- withFavoredNodes(InetSocketAddress[]) - Method in class org.apache.hadoop.hbase.io.hfile.HFile.WriterFactory
- withFavoredNodes(InetSocketAddress[]) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileWriter.Builder
- withFavoredNodesSupplier(Supplier<InetSocketAddress[]>) - Method in class org.apache.hadoop.hbase.regionserver.StoreContext.Builder
- withFileContext(HFileContext) - Method in class org.apache.hadoop.hbase.io.hfile.HFile.WriterFactory
- withFileContext(HFileContext) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileWriter.Builder
- withFilePath(Path) - Method in class org.apache.hadoop.hbase.io.hfile.ReaderContextBuilder
- withFilePath(Path) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileWriter.Builder
-
Use either this method or
StoreFileWriter.Builder.withOutputDir(org.apache.hadoop.fs.Path)
, but not both. - withFileSize(long) - Method in class org.apache.hadoop.hbase.io.hfile.ReaderContextBuilder
- withFileStoragePolicy(String) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileWriter.Builder
- withFileSystem(FileSystem) - Method in class org.apache.hadoop.hbase.io.hfile.ReaderContextBuilder
- withFileSystem(HFileSystem) - Method in class org.apache.hadoop.hbase.io.hfile.ReaderContextBuilder
- withFileSystemAndPath(FileSystem, Path) - Method in class org.apache.hadoop.hbase.io.hfile.ReaderContextBuilder
- withFillHeader(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockBuilder
- withFromTables(TableName[]) - Method in class org.apache.hadoop.hbase.backup.RestoreRequest.Builder
- withHBaseCheckSum(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileContextBuilder
- withHFileContext(HFileContext) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockBuilder
- withHFileName(String) - Method in class org.apache.hadoop.hbase.io.hfile.HFileContextBuilder
- withIncludesMvcc(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileContextBuilder
- withIncludesTags(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileContextBuilder
- withIndexBlockEncoding(IndexBlockEncoding) - Method in class org.apache.hadoop.hbase.io.hfile.HFileContextBuilder
- withinOrAfterTimeRange(long) - Method in class org.apache.hadoop.hbase.io.TimeRange
-
Check if the specified timestamp is within or after this TimeRange.
- withInputStreamWrapper(FSDataInputStreamWrapper) - Method in class org.apache.hadoop.hbase.io.hfile.ReaderContextBuilder
- withinTimeRange(long) - Method in class org.apache.hadoop.hbase.io.TimeRange
-
Check if the specified timestamp is within this TimeRange.
- withIsCompaction(boolean) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileWriter.Builder
- withMaxCacheSize(long) - Method in class org.apache.hadoop.hbase.CacheEvictionStatsBuilder
- withMaxKeyCount(long) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileWriter.Builder
- withMaxVersions(int) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileWriter.Builder
- withNewVersionBehavior(boolean) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileWriter.Builder
- withNextBlockOnDiskSize(int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockBuilder
- withNoChecksumVerify(boolean) - Method in class org.apache.hadoop.hbase.backup.BackupRequest.Builder
- withOffset(long) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockBuilder
- withOnDiskDataSizeWithHeader(int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockBuilder
- withOnDiskSizeWithoutHeader(int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockBuilder
- withOutputDir(Path) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileWriter.Builder
-
Use either this method or
StoreFileWriter.Builder.withFilePath(org.apache.hadoop.fs.Path)
, but not both. - withOutputStream(FSDataOutputStream) - Method in class org.apache.hadoop.hbase.io.hfile.HFile.WriterFactory
- withOvewrite(boolean) - Method in class org.apache.hadoop.hbase.backup.RestoreRequest.Builder
- withParameters(Class<?>...) - Method in class org.apache.hadoop.hbase.tool.coprocessor.CoprocessorMethod
- withParameters(String...) - Method in class org.apache.hadoop.hbase.tool.coprocessor.CoprocessorMethod
- withPath(FileSystem, Path) - Method in class org.apache.hadoop.hbase.io.hfile.HFile.WriterFactory
- withPrevBlockOffset(long) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockBuilder
- withPrimaryReplicaReader(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.ReaderContextBuilder
- withReaderType(ReaderContext.ReaderType) - Method in class org.apache.hadoop.hbase.io.hfile.ReaderContextBuilder
- withRegionCoprocessorHost(RegionCoprocessorHost) - Method in class org.apache.hadoop.hbase.regionserver.StoreContext.Builder
- withRegionFileSystem(HRegionFileSystem) - Method in class org.apache.hadoop.hbase.regionserver.StoreContext.Builder
- withRestoreRootDir(String) - Method in class org.apache.hadoop.hbase.backup.RestoreRequest.Builder
- withShared(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockBuilder
- withShouldDropCacheBehind(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFile.WriterFactory
- withShouldDropCacheBehind(boolean) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileWriter.Builder
- withStartRow(byte[]) - Method in class org.apache.hadoop.hbase.client.ImmutableScan
- withStartRow(byte[]) - Method in class org.apache.hadoop.hbase.client.Scan
-
Set the start row of the scan.
- withStartRow(byte[], boolean) - Method in class org.apache.hadoop.hbase.client.ImmutableScan
- withStartRow(byte[], boolean) - Method in class org.apache.hadoop.hbase.client.Scan
-
Set the start row of the scan.
- withStopRow(byte[]) - Method in class org.apache.hadoop.hbase.client.ImmutableScan
- withStopRow(byte[]) - Method in class org.apache.hadoop.hbase.client.Scan
-
Set the stop row of the scan.
- withStopRow(byte[], boolean) - Method in class org.apache.hadoop.hbase.client.ImmutableScan
- withStopRow(byte[], boolean) - Method in class org.apache.hadoop.hbase.client.Scan
-
Set the stop row of the scan.
- withTableList(List<TableName>) - Method in class org.apache.hadoop.hbase.backup.BackupRequest.Builder
- withTableName(byte[]) - Method in class org.apache.hadoop.hbase.io.hfile.HFileContextBuilder
- withTargetRootDir(String) - Method in class org.apache.hadoop.hbase.backup.BackupRequest.Builder
- withToTables(TableName[]) - Method in class org.apache.hadoop.hbase.backup.RestoreRequest.Builder
- withTotalTasks(int) - Method in class org.apache.hadoop.hbase.backup.BackupRequest.Builder
- withUncompressedSizeWithoutHeader(int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockBuilder
- withWriterCreationTracker(Consumer<Path>) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileWriter.Builder
- withYarnPoolName(String) - Method in class org.apache.hadoop.hbase.backup.BackupRequest.Builder
- WORKER_THREADS_CONF_KEY - Static variable in class org.apache.hadoop.hbase.thrift.HThreadedSelectorServerArgs
-
Number fo threads for processing the thrift calls
- org.apache.hadoop.hbase.master.WorkerAssigner - Class in org.apache.hadoop.hbase.master
-
help assign and release a worker for each remote task.
- WorkerAssigner(MasterServices, int, ProcedureEvent<?>) - Constructor for class org.apache.hadoop.hbase.master.WorkerAssigner
- wrap(byte[]) - Static method in class org.apache.hadoop.hbase.util.ImmutableByteArray
- wrap(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.crypto.aes.CryptoAES
-
Encrypts input data.
- wrap(byte[], int, int) - Method in class org.apache.hadoop.hbase.security.HBaseSaslRpcServer
- wrap(byte[], int, int) - Method in interface org.apache.hadoop.hbase.security.SaslWrapHandler.Wrapper
- wrap(ByteBuffer) - Static method in class org.apache.hadoop.hbase.nio.ByteBuff
- wrap(ByteBuffer[]) - Static method in class org.apache.hadoop.hbase.nio.ByteBuff
- wrap(ByteBuffer[], ByteBuffAllocator.Recycler) - Static method in class org.apache.hadoop.hbase.nio.ByteBuff
- wrap(ByteBuffer[], RefCnt) - Static method in class org.apache.hadoop.hbase.nio.ByteBuff
-
In theory, the upstream should never construct an ByteBuff by passing an given refCnt, so please don't use this public method in other place.
- wrap(List<ByteBuffer>) - Static method in class org.apache.hadoop.hbase.nio.ByteBuff
- wrap(List<ByteBuffer>, ByteBuffAllocator.Recycler) - Static method in class org.apache.hadoop.hbase.nio.ByteBuff
- wrapFuture(CompletableFuture<T>, Executor) - Static method in class org.apache.hadoop.hbase.util.FutureUtils
-
Return a
CompletableFuture
which is same with the givenfuture
, but execute all the callbacks in the givenexecutor
. - wrapKey(Configuration, byte[], String) - Static method in class org.apache.hadoop.hbase.security.EncryptionUtil
-
Protect a key by encrypting it with the secret key of the given subject.
- wrapKey(Configuration, String, Key) - Static method in class org.apache.hadoop.hbase.security.EncryptionUtil
-
Protect a key by encrypting it with the secret key of the given subject.
- wrapped - Variable in class org.apache.hadoop.hbase.types.TerminatedWrapper
- org.apache.hadoop.hbase.io.asyncfs.WrapperAsyncFSOutput - Class in org.apache.hadoop.hbase.io.asyncfs
-
An
AsyncFSOutput
wraps aFSDataOutputStream
. - WrapperAsyncFSOutput(Path, FSDataOutputStream) - Constructor for class org.apache.hadoop.hbase.io.asyncfs.WrapperAsyncFSOutput
- org.apache.hadoop.hbase.util.Writables - Class in org.apache.hadoop.hbase.util
-
Utility class with methods for manipulating Writable objects
- Writables() - Constructor for class org.apache.hadoop.hbase.util.Writables
- org.apache.hadoop.hbase.io.WritableWithSize - Interface in org.apache.hadoop.hbase.io
-
An optional interface to 'size' writables.
- write(byte[]) - Method in interface org.apache.hadoop.hbase.io.asyncfs.AsyncFSOutput
-
Just call write(b, 0, b.length).
- write(byte[]) - Method in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutput
- write(byte[]) - Method in class org.apache.hadoop.hbase.io.asyncfs.WrapperAsyncFSOutput
- write(byte[]) - Method in class org.apache.hadoop.hbase.io.ByteBufferOutputStream
- write(byte[]) - Method in class org.apache.hadoop.hbase.util.RotateFile
-
Writes the given data to the next file in the rotation, with a timestamp calculated based on the previous timestamp and the current time to make sure it is greater than the previous timestamp.
- write(byte[], int, int) - Method in interface org.apache.hadoop.hbase.io.asyncfs.AsyncFSOutput
-
Copy the data into the buffer.
- write(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutput
- write(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.asyncfs.WrapperAsyncFSOutput
- write(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.ByteArrayOutputStream
- write(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.ByteBufferListOutputStream
- write(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.ByteBufferOutputStream
- write(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.ByteBufferWriterOutputStream
- write(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.compress.ReusableStreamGzipCodec.ReusableGzipOutputStream
- write(int) - Method in class org.apache.hadoop.hbase.io.ByteArrayOutputStream
- write(int) - Method in class org.apache.hadoop.hbase.io.ByteBufferOutputStream
- write(int) - Method in class org.apache.hadoop.hbase.io.ByteBufferWriterOutputStream
- write(int) - Method in class org.apache.hadoop.hbase.io.compress.ReusableStreamGzipCodec.ReusableGzipOutputStream
- write(long, ByteBuff) - Method in class org.apache.hadoop.hbase.util.ByteBufferArray
-
Transfers bytes from the given source
ByteBuff
into this buffer array - write(DataOutput) - Method in class org.apache.hadoop.hbase.CompoundConfiguration
- write(DataOutput) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
- write(DataOutput) - Method in enum class org.apache.hadoop.hbase.io.hfile.BlockType
- write(DataOutput) - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
- write(DataOutput) - Method in class org.apache.hadoop.hbase.mapred.TableSnapshotInputFormat.TableSnapshotRegionSplit
- write(DataOutput) - Method in class org.apache.hadoop.hbase.mapred.TableSplit
- write(DataOutput) - Method in class org.apache.hadoop.hbase.mapreduce.Import.CellWritableComparable
- write(DataOutput) - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormat.TableSnapshotRegionSplit
- write(DataOutput) - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.InputSplit
- write(DataOutput) - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
-
Writes the field values to the output.
- write(DataOutput) - Method in enum class org.apache.hadoop.hbase.security.AuthMethod
-
Write to out
- write(OutputStream) - Method in class org.apache.hadoop.hbase.rest.ProtobufStreamingOutput
- write(OutputStream, boolean) - Method in class org.apache.hadoop.hbase.ByteBufferKeyValue
- write(OutputStream, boolean) - Method in interface org.apache.hadoop.hbase.ExtendedCell
-
Write this cell to an OutputStream in a
KeyValue
format. - write(OutputStream, boolean) - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
- write(OutputStream, boolean) - Method in class org.apache.hadoop.hbase.KeyValue
- write(OutputStream, boolean) - Method in class org.apache.hadoop.hbase.NoTagsKeyValue
- write(OutputStream, boolean) - Method in class org.apache.hadoop.hbase.SizeCachedNoTagsKeyValue
- write(OutputStream, boolean) - Method in class org.apache.hadoop.hbase.util.MapReduceExtendedCell
- write(OutputStream, byte[], int, int, Dictionary) - Static method in interface org.apache.hadoop.hbase.io.util.Dictionary
-
Helper methods to write the dictionary data to the OutputStream
- write(OutputStream, ByteBuffer, int, int, Dictionary) - Static method in interface org.apache.hadoop.hbase.io.util.Dictionary
-
Helper methods to write the dictionary data to the OutputStream
- write(OutputStream, ByteRange) - Static method in class org.apache.hadoop.hbase.util.ByteRangeUtils
- write(OutputStream, ByteRange, int) - Static method in class org.apache.hadoop.hbase.util.ByteRangeUtils
- write(String, String) - Method in interface org.apache.hadoop.hbase.util.JSONBean.Writer
- write(ByteBuffer) - Method in interface org.apache.hadoop.hbase.io.asyncfs.AsyncFSOutput
-
Copy the data in the given
bb
into the buffer. - write(ByteBuffer) - Method in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutput
- write(ByteBuffer) - Method in class org.apache.hadoop.hbase.io.asyncfs.WrapperAsyncFSOutput
- write(ByteBuffer) - Method in enum class org.apache.hadoop.hbase.io.hfile.BlockType
- write(ByteBuffer, int) - Method in class org.apache.hadoop.hbase.ByteBufferKeyValue
- write(ByteBuffer, int) - Method in interface org.apache.hadoop.hbase.ExtendedCell
-
Write this Cell into the given buf's offset in a
KeyValue
format. - write(ByteBuffer, int) - Method in class org.apache.hadoop.hbase.KeyValue
- write(ByteBuffer, int) - Method in class org.apache.hadoop.hbase.util.MapReduceExtendedCell
- write(ByteBuffer, int, int) - Method in class org.apache.hadoop.hbase.io.ByteArrayOutputStream
- write(ByteBuffer, int, int) - Method in class org.apache.hadoop.hbase.io.ByteBufferListOutputStream
- write(ByteBuffer, int, int) - Method in class org.apache.hadoop.hbase.io.ByteBufferOutputStream
- write(ByteBuffer, int, int) - Method in interface org.apache.hadoop.hbase.io.ByteBufferWriter
-
Writes
len
bytes from the specified ByteBuffer starting at offsetoff
- write(ByteBuffer, int, int) - Method in class org.apache.hadoop.hbase.io.ByteBufferWriterDataOutputStream
- write(ByteBuffer, int, int) - Method in class org.apache.hadoop.hbase.io.ByteBufferWriterOutputStream
-
Writes len bytes from the specified ByteBuffer starting at offset off to this OutputStream.
- write(FileChannel, long) - Method in class org.apache.hadoop.hbase.nio.ByteBuff
-
Write this ByteBuff's data into target file
- write(FileChannel, long) - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
- write(FileChannel, long) - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
- write(MBeanServer, ObjectName, String, boolean) - Method in interface org.apache.hadoop.hbase.util.JSONBean.Writer
- write(MBeanServer, ObjectName, String, boolean, ObjectName) - Method in interface org.apache.hadoop.hbase.util.JSONBean.Writer
- write(KEY, Mutation) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputFormat.TableRecordWriter
-
Writes a key/value pair into the table.
- write(FileSystem, Path) - Method in class org.apache.hadoop.hbase.io.Reference
- write(ExtendedCell) - Method in class org.apache.hadoop.hbase.codec.BaseEncoder
- write(ExtendedCell) - Method in class org.apache.hadoop.hbase.codec.KeyValueCodec.KeyValueEncoder
- write(ExtendedCell) - Method in class org.apache.hadoop.hbase.codec.KeyValueCodecWithTags.KeyValueEncoder
- write(ExtendedCell) - Method in interface org.apache.hadoop.hbase.io.CellOutputStream
-
Implementation must copy the entire state of the Cell.
- write(ExtendedCell) - Method in class org.apache.hadoop.hbase.io.encoding.NoneEncoder
- write(ExtendedCell) - Method in class org.apache.hadoop.hbase.io.encoding.RowIndexEncoderV1
- write(ExtendedCell) - Method in class org.apache.hadoop.hbase.regionserver.wal.WALCellCodec.EnsureKvEncoder
- write(ImmutableBytesWritable, Mutation) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableOutputFormat.MultiTableRecordWriter
-
Writes an action (Put or Delete) to the specified table.
- write(ImmutableBytesWritable, Put) - Method in class org.apache.hadoop.hbase.mapred.TableOutputFormat.TableRecordWriter
- write(KeyValue, DataOutput) - Static method in class org.apache.hadoop.hbase.KeyValue
-
Write out a KeyValue in the manner in which we used to when KeyValue was a Writable.
- write(KeyValue, DataOutput) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
-
Write out a KeyValue in the manner in which we used to when KeyValue was a Writable.
- write(ByteBuff) - Method in enum class org.apache.hadoop.hbase.io.hfile.BlockType
- write(ChannelHandlerContext, Object, ChannelPromise) - Method in class org.apache.hadoop.hbase.ipc.NettyRpcServerChannelWritabilityHandler
- WRITE_BUFFER_PERIODIC_FLUSH_TIMEOUT_MS - Static variable in class org.apache.hadoop.hbase.client.ConnectionConfiguration
- WRITE_BUFFER_PERIODIC_FLUSH_TIMEOUT_MS_DEFAULT - Static variable in class org.apache.hadoop.hbase.client.ConnectionConfiguration
- WRITE_BUFFER_PERIODIC_FLUSH_TIMERTICK_MS - Static variable in class org.apache.hadoop.hbase.client.ConnectionConfiguration
- WRITE_BUFFER_PERIODIC_FLUSH_TIMERTICK_MS_DEFAULT - Static variable in class org.apache.hadoop.hbase.client.ConnectionConfiguration
- WRITE_BUFFER_SIZE_DEFAULT - Static variable in class org.apache.hadoop.hbase.client.ConnectionConfiguration
- WRITE_BUFFER_SIZE_KEY - Static variable in class org.apache.hadoop.hbase.client.ConnectionConfiguration
- WRITE_CAPACITY_UNIT - Enum constant in enum class org.apache.hadoop.hbase.quotas.ThrottleType
-
Throttling based on the write data capacity unit
- WRITE_CAPACITY_UNIT_CONF_KEY - Static variable in class org.apache.hadoop.hbase.quotas.QuotaUtil
- WRITE_NUMBER - Enum constant in enum class org.apache.hadoop.hbase.quotas.ThrottleType
-
Throttling based on the number of write requests per time-unit
- WRITE_OPERATION_LATENCY_DESC - Static variable in interface org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSource
- WRITE_OPERATION_LATENCY_NAME - Static variable in interface org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSource
- WRITE_QUEUE_DESC - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
- WRITE_QUEUE_NAME - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
- WRITE_REQUEST_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- WRITE_REQUEST_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- WRITE_REQUEST_COUNT_PER_SECOND - Enum constant in enum class org.apache.hadoop.hbase.hbtop.field.Field
- WRITE_REQUEST_RATE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- WRITE_REQUEST_RATE_PER_SECOND - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- WRITE_SIZE - Enum constant in enum class org.apache.hadoop.hbase.quotas.ThrottleType
-
Throttling based on the write data size
- writeBloom(DataOutput) - Method in class org.apache.hadoop.hbase.util.BloomFilterChunk
-
Writes just the bloom filter to the output array
- writeBloom(ExtendedCell) - Method in class org.apache.hadoop.hbase.util.BloomContext
-
Bloom information from the cell is retrieved
- writeBloom(ExtendedCell) - Method in class org.apache.hadoop.hbase.util.RowPrefixFixedLengthBloomContext
- writeBufferSize(long) - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
-
Override the write buffer size specified by the provided
Connection
'sConfiguration
instance, via the configuration keyhbase.client.write.buffer
. - writeBulkLoadMarkerAndSync(WAL, NavigableMap<byte[], Integer>, RegionInfo, WALProtos.BulkLoadDescriptor, MultiVersionConcurrencyControl, RegionReplicationSink) - Static method in class org.apache.hadoop.hbase.regionserver.wal.WALUtil
-
Write a log marker that a bulk load has succeeded and is about to be committed.
- writeByteArray(byte[], int, byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Write byte-array from src to tgt with a vint length prefix.
- writeByteArray(byte[], int, byte[], int, int, byte[], int, int, byte[], int, int, long, KeyValue.Type, byte[], int, int, Tag[]) - Static method in class org.apache.hadoop.hbase.KeyValue
-
Write KeyValue format into the provided byte array.
- writeByteArray(DataOutput, byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Write byte-array with a WritableableUtils.vint prefix.
- writeByteArray(DataOutput, byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Write byte-array to out with a vint length prefix.
- writeCapacityUnitConsumed - Variable in class org.apache.hadoop.hbase.quotas.DefaultOperationQuota
- writeCapacityUnitDiff - Variable in class org.apache.hadoop.hbase.quotas.DefaultOperationQuota
- WriteCapacityUnitExceeded - Enum constant in enum class org.apache.hadoop.hbase.quotas.RpcThrottlingException.Type
- writeCompactionMarker(WAL, NavigableMap<byte[], Integer>, RegionInfo, WALProtos.CompactionDescriptor, MultiVersionConcurrencyControl, RegionReplicationSink) - Static method in class org.apache.hadoop.hbase.regionserver.wal.WALUtil
-
Write the marker that a compaction has succeeded and is about to be committed.
- writeConsumed - Variable in class org.apache.hadoop.hbase.quotas.DefaultOperationQuota
- writeDiff - Variable in class org.apache.hadoop.hbase.quotas.DefaultOperationQuota
- WriteExampleCallable(Connection, TableName) - Constructor for class org.apache.hadoop.hbase.client.example.MultiThreadedClientExample.WriteExampleCallable
- writeFamily(OutputStream, Cell, byte) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
Writes the family from the given cell to the output stream
- writeFileInfo(FixedFileTrailer, DataOutputStream) - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterImpl
-
Sets the file info offset in the trailer, finishes up populating fields in the file info, and writes the file info into the given data output.
- writeFlatKey(ExtendedCell, DataOutput) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
Writes the Cell's key part as it would have serialized in a KeyValue.
- writeFlatKey(ExtendedCell, OutputStream) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
- writeFlushMarker(WAL, NavigableMap<byte[], Integer>, RegionInfo, WALProtos.FlushDescriptor, boolean, MultiVersionConcurrencyControl, RegionReplicationSink) - Static method in class org.apache.hadoop.hbase.regionserver.wal.WALUtil
-
Write a flush marker indicating a start / abort or a complete of a region flush
- writeIdInBytes(byte[], int) - Method in enum class org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
-
Writes id bytes to the given array starting from offset.
- writeIdInBytes(byte[], int) - Method in enum class org.apache.hadoop.hbase.io.encoding.IndexBlockEncoding
-
Writes id bytes to the given array starting from offset.
- writeIdInBytes(OutputStream) - Method in enum class org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
-
Writes id in bytes.
- writeIdInBytes(OutputStream) - Method in enum class org.apache.hadoop.hbase.io.encoding.IndexBlockEncoding
-
Writes id in bytes.
- writeIndexBlocks(FSDataOutputStream) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexWriter
-
Writes the root level and intermediate levels of the block index into the output stream, generating the tree from bottom up.
- writeInlineBlock(DataOutput) - Method in class org.apache.hadoop.hbase.io.hfile.CompoundBloomFilterWriter
- writeInlineBlock(DataOutput) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexWriter
-
Write out the current inline index block.
- writeInlineBlock(DataOutput) - Method in interface org.apache.hadoop.hbase.io.hfile.InlineBlockWriter
-
Writes the block to the provided stream.
- writeInt(int) - Method in interface org.apache.hadoop.hbase.io.asyncfs.AsyncFSOutput
-
Write an int to the buffer.
- writeInt(int) - Method in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutput
- writeInt(int) - Method in class org.apache.hadoop.hbase.io.asyncfs.WrapperAsyncFSOutput
- writeInt(int) - Method in class org.apache.hadoop.hbase.io.ByteArrayOutputStream
- writeInt(int) - Method in class org.apache.hadoop.hbase.io.ByteBufferOutputStream
-
Writes an
int
to the underlying output stream as four bytes, high byte first. - writeInt(int) - Method in interface org.apache.hadoop.hbase.io.ByteBufferWriter
-
Writes an
int
to the underlying output stream as four bytes, high byte first. - writeInt(int) - Method in class org.apache.hadoop.hbase.io.ByteBufferWriterOutputStream
- writeInt(OutputStream, int) - Static method in class org.apache.hadoop.hbase.io.util.StreamUtils
- writeLock() - Method in class org.apache.hadoop.hbase.regionserver.StoreEngine
-
Acquire write lock of this store.
- writeLong(OutputStream, long) - Static method in class org.apache.hadoop.hbase.io.util.StreamUtils
- writeMagicAndWALHeader(byte[], WALProtos.WALHeader) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractProtobufLogWriter
-
return the file length after written.
- writeMagicAndWALHeader(byte[], WALProtos.WALHeader) - Method in class org.apache.hadoop.hbase.regionserver.wal.AsyncProtobufLogWriter
- writeMagicAndWALHeader(byte[], WALProtos.WALHeader) - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogWriter
- writeMapAsString(Map<String, Object>) - Static method in class org.apache.hadoop.hbase.util.JsonMapper
- writeMyEphemeralNodeOnDisk(String) - Static method in class org.apache.hadoop.hbase.ZNodeClearer
-
Logs the errors without failing on exception.
- writeObjectAsString(Object) - Static method in class org.apache.hadoop.hbase.util.JsonMapper
- writeProtobufOutput(OutputStream) - Method in interface org.apache.hadoop.hbase.rest.ProtobufMessageHandler
-
Writes the protobuf represention of the model to os
- writeQualifier(OutputStream, Cell, int) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
Writes the qualifier from the given cell to the output stream
- writeQualifierSkippingBytes(DataOutputStream, Cell, int, int) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
Writes the qualifier from the given cell to the output stream excluding the common prefix
- writer - Variable in class org.apache.hadoop.hbase.util.MultiThreadedReader
- WRITER_IMPL - Static variable in class org.apache.hadoop.hbase.wal.AsyncFSWALProvider
- WRITER_IMPL - Static variable in class org.apache.hadoop.hbase.wal.FSHLogProvider
- writeRawVInt32(OutputStream, int) - Static method in class org.apache.hadoop.hbase.io.util.StreamUtils
- writerCreationTracker() - Method in class org.apache.hadoop.hbase.regionserver.CreateStoreFileWriterParams
- writerCreationTracker(Consumer<Path>) - Method in class org.apache.hadoop.hbase.regionserver.CreateStoreFileWriterParams
- writeRegionEventMarker(WAL, NavigableMap<byte[], Integer>, RegionInfo, WALProtos.RegionEventDescriptor, MultiVersionConcurrencyControl, RegionReplicationSink) - Static method in class org.apache.hadoop.hbase.regionserver.wal.WALUtil
-
Write a region open marker indicating that the region is opened.
- writeRegionOpenMarker(WAL, long) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
- writeRegionSequenceIdFile(FileSystem, Path, long) - Static method in class org.apache.hadoop.hbase.wal.WALSplitUtil
-
Create a file with name as region's max sequence id
- writeReplicationMarkerAndSync(WAL, MultiVersionConcurrencyControl, RegionInfo, byte[], long) - Static method in class org.apache.hadoop.hbase.regionserver.wal.WALUtil
- writerFactory - Variable in class org.apache.hadoop.hbase.regionserver.AbstractMultiFileWriter
-
Factory that is used to produce single StoreFile.Writer-s
- writeRow(OutputStream, Cell, short) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
Writes the row from the given cell to the output stream
- writeRowKeyExcludingCommon(Cell, short, int, DataOutputStream) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
Write rowkey excluding the common part.
- writeRowSkippingBytes(DataOutputStream, Cell, short, int) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
Writes the row from the given cell to the output stream excluding the common prefix
- writers - Variable in class org.apache.hadoop.hbase.regionserver.wal.CombinedWriterBase
- writers - Variable in class org.apache.hadoop.hbase.util.MultiThreadedWriter
- writers() - Method in class org.apache.hadoop.hbase.regionserver.AbstractMultiFileWriter
- writers() - Method in class org.apache.hadoop.hbase.regionserver.DateTieredMultiFileWriter
- writers() - Method in class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter
- writerThreads - Variable in class org.apache.hadoop.hbase.util.LoadTestTool
- writeShort(OutputStream, short) - Static method in class org.apache.hadoop.hbase.io.util.StreamUtils
- writeSingleLevelIndex(DataOutput, String) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexWriter
-
Writes the block index data as a single level only.
- WriteSizeExceeded - Enum constant in enum class org.apache.hadoop.hbase.quotas.RpcThrottlingException.Type
- writeSnapshotInfo(SnapshotProtos.SnapshotDescription, Path, FileSystem) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
Write the snapshot description into the working directory of a snapshot
- writeStringFixedSize(DataOutput, String, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Writes a string as a fixed-size field, padded with zeros.
- writeTags(OutputStream, ExtendedCell, int) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
Writes the tag from the given cell to the output stream
- writeTo(OutputStream) - Method in class org.apache.hadoop.hbase.io.ByteBufferListOutputStream
- writeTo(OutputStream) - Method in class org.apache.hadoop.hbase.io.ByteBufferOutputStream
-
Writes the complete contents of this byte buffer output stream to the specified output stream argument.
- writeTo(PrintStream) - Static method in class org.apache.hadoop.hbase.util.VersionInfo
- writeTo(PrintWriter) - Static method in class org.apache.hadoop.hbase.util.VersionInfo
- writeTo(T, Class<?>, Type, Annotation[], MediaType, MultivaluedMap<String, Object>, OutputStream) - Method in class org.apache.hadoop.hbase.http.gson.GsonMessageBodyWriter
- writeTO - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
- writeToStream(OutputStream) - Method in enum class org.apache.hadoop.hbase.io.hfile.BlockType
- writeUnlock() - Method in class org.apache.hadoop.hbase.regionserver.StoreEngine
-
Release write lock of this store.
- writeValue(OutputStream, ExtendedCell, int) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
Writes the value from the given cell to the output stream
- writeVLong(ByteBuffer, long) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Similar to
WritableUtils.writeVLong(java.io.DataOutput, long)
, but writes to aByteBuffer
. - writeWALTrailer() - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractProtobufLogWriter
- writeWALTrailerAndMagic(WALProtos.WALTrailer, byte[]) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractProtobufLogWriter
- writeWALTrailerAndMagic(WALProtos.WALTrailer, byte[]) - Method in class org.apache.hadoop.hbase.regionserver.wal.AsyncProtobufLogWriter
- writeWALTrailerAndMagic(WALProtos.WALTrailer, byte[]) - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogWriter
- writeXml(OutputStream) - Method in class org.apache.hadoop.hbase.CompoundConfiguration
- writeXml(OutputStream) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
- writeXml(Writer) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
- WRITTEN_BYTES - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
- WRITTEN_BYTES_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
- WRONG_USAGE - Enum constant in enum class org.apache.hadoop.hbase.util.HbckErrorReporter.ERROR_CODE
-
Deprecated.
- org.apache.hadoop.hbase.regionserver.WrongRegionException - Exception in org.apache.hadoop.hbase.regionserver
-
Thrown when a request contains a key which is not part of this region
- WrongRegionException() - Constructor for exception org.apache.hadoop.hbase.regionserver.WrongRegionException
-
constructor
- WrongRegionException(String) - Constructor for exception org.apache.hadoop.hbase.regionserver.WrongRegionException
-
Constructor
- org.apache.hadoop.hbase.client.WrongRowIOException - Exception in org.apache.hadoop.hbase.client
- WrongRowIOException(String) - Constructor for exception org.apache.hadoop.hbase.client.WrongRowIOException
- org.apache.hadoop.hbase.ipc.WrongVersionException - Exception in org.apache.hadoop.hbase.ipc
- WrongVersionException() - Constructor for exception org.apache.hadoop.hbase.ipc.WrongVersionException
- WrongVersionException(String) - Constructor for exception org.apache.hadoop.hbase.ipc.WrongVersionException
- WrongVersionException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.ipc.WrongVersionException
- wroteKeyQueueSize - Variable in class org.apache.hadoop.hbase.util.MultiThreadedWriterBase
-
The total size of the temporary inserted/updated key set that have not yet lined up in a our contiguous sequence starting from startKey.
- wroteKeys - Variable in class org.apache.hadoop.hbase.util.MultiThreadedWriterBase
-
A temporary place to keep track of inserted/updated keys.
- wroteUpToKey - Variable in class org.apache.hadoop.hbase.util.MultiThreadedWriterBase
-
The highest key in the contiguous range of keys .
- wroteUpToKey() - Method in class org.apache.hadoop.hbase.util.MultiThreadedWriterBase
-
The max key until which all keys have been inserted/updated (successfully or not).
X
- org.apache.hadoop.hbase.exceptions.X509Exception - Exception in org.apache.hadoop.hbase.exceptions
-
This file has been copied from the Apache ZooKeeper project.
- X509Exception(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.X509Exception
- X509Exception(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.exceptions.X509Exception
- X509Exception(Throwable) - Constructor for exception org.apache.hadoop.hbase.exceptions.X509Exception
- org.apache.hadoop.hbase.io.crypto.tls.X509Util - Class in org.apache.hadoop.hbase.io.crypto.tls
-
Utility code for X509 handling Default cipher suites: Performance testing done by Facebook engineers shows that on Intel x86_64 machines, Java9 performs better with GCM and Java8 performs better with CBC, so these seem like reasonable defaults.
- org.apache.hadoop.hbase.io.crypto.tls.X509Util.ClientAuth - Enum Class in org.apache.hadoop.hbase.io.crypto.tls
-
Enum specifying the client auth requirement of server-side TLS sockets created by this X509Util.
- XOR - Enum constant in enum class org.apache.hadoop.hbase.filter.BitComparator.BitwiseOp
-
xor
Y
- org.apache.hadoop.hbase.util.YammerHistogramUtils - Class in org.apache.hadoop.hbase.util
-
Utility functions for working with Yammer Metrics.
- YELLOW - Enum constant in enum class org.apache.hadoop.hbase.hbtop.terminal.Color
- org.apache.hadoop.hbase.YouAreDeadException - Exception in org.apache.hadoop.hbase
-
This exception is thrown by the master when a region server reports and is already being processed as dead.
- YouAreDeadException(String) - Constructor for exception org.apache.hadoop.hbase.YouAreDeadException
Z
- zero(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Fill given array with zeros.
- zero(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Fill given array with zeros at the specified position.
- ZERO - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
ASCII code for Zero
- ZERO - Static variable in class org.apache.hadoop.hbase.Size
- ZERO_L - Static variable in class org.apache.hadoop.hbase.HConstants
-
long constant for zero
- ZEROCOPY_BYTES_READ - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- ZEROCOPY_BYTES_READ_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- ZEROES - Static variable in class org.apache.hadoop.hbase.HConstants
- Zipf(Random, int, int, double) - Constructor for class org.apache.hadoop.hbase.util.RandomDistribution.Zipf
-
Constructor The random number generator.
- Zipf(Random, int, int, double, double) - Constructor for class org.apache.hadoop.hbase.util.RandomDistribution.Zipf
-
Constructor.
- ZK_CFG_PROPERTY_PREFIX - Static variable in class org.apache.hadoop.hbase.HConstants
-
Common prefix of ZooKeeper configuration properties
- ZK_CFG_PROPERTY_PREFIX_LEN - Static variable in class org.apache.hadoop.hbase.HConstants
- ZK_CLIENT_KERBEROS_PRINCIPAL - Static variable in class org.apache.hadoop.hbase.HConstants
- ZK_CLIENT_KEYTAB_FILE - Static variable in class org.apache.hadoop.hbase.HConstants
-
Configuration keys for programmatic JAAS configuration for secured ZK interaction
- ZK_CONNECTION_REGISTRY_CLASS - Static variable in class org.apache.hadoop.hbase.HConstants
-
Full class name of the Zookeeper based connection registry implementation
- ZK_SERVER_KERBEROS_PRINCIPAL - Static variable in class org.apache.hadoop.hbase.HConstants
- ZK_SERVER_KEYTAB_FILE - Static variable in class org.apache.hadoop.hbase.HConstants
- ZK_SESSION_TIMEOUT - Static variable in class org.apache.hadoop.hbase.HConstants
-
Configuration key for ZooKeeper session timeout
- ZK_SYNC_BLOCKING_TIMEOUT_DEFAULT_MS - Static variable in class org.apache.hadoop.hbase.HConstants
- ZK_SYNC_BLOCKING_TIMEOUT_MS - Static variable in class org.apache.hadoop.hbase.HConstants
-
Timeout for the ZK sync() call
- org.apache.hadoop.hbase.zookeeper.ZKAclReset - Class in org.apache.hadoop.hbase.zookeeper
-
You may add the jaas.conf option -Djava.security.auth.login.config=/PATH/jaas.conf You may also specify -D to set options "hbase.zookeeper.quorum" (it should be in hbase-site.xml) "zookeeper.znode.parent" (it should be in hbase-site.xml) Use -set-acls to set the ACLs, no option to erase ACLs
- ZKAclReset() - Constructor for class org.apache.hadoop.hbase.zookeeper.ZKAclReset
- org.apache.hadoop.hbase.zookeeper.ZKAuthentication - Class in org.apache.hadoop.hbase.zookeeper
-
Provides ZooKeeper authentication services for both client and server processes.
- org.apache.hadoop.hbase.zookeeper.ZKClusterId - Class in org.apache.hadoop.hbase.zookeeper
-
Publishes and synchronizes a unique identifier specific to a given HBase cluster.
- ZKClusterId(ZKWatcher, Abortable) - Constructor for class org.apache.hadoop.hbase.zookeeper.ZKClusterId
- org.apache.hadoop.hbase.zookeeper.ZKConfig - Class in org.apache.hadoop.hbase.zookeeper
-
Utility methods for reading, and building the ZooKeeper configuration.
- org.apache.hadoop.hbase.zookeeper.ZKConfig.ZKClusterKey - Class in org.apache.hadoop.hbase.zookeeper
- org.apache.hadoop.hbase.client.ZKConnectionRegistryURIFactory - Class in org.apache.hadoop.hbase.client
-
Connection registry creator implementation for creating
ZKConnectionRegistry
. - ZKConnectionRegistryURIFactory() - Constructor for class org.apache.hadoop.hbase.client.ZKConnectionRegistryURIFactory
- org.apache.hadoop.hbase.coordination.ZkCoordinatedStateManager - Class in org.apache.hadoop.hbase.coordination
-
Deprecated.since 2.4.0 and in 3.0.0, to be removed in 4.0.0, replaced by procedure-based distributed WAL splitter (see SplitWALManager) which doesn't use this zk-based coordinator.
- ZkCoordinatedStateManager(Server) - Constructor for class org.apache.hadoop.hbase.coordination.ZkCoordinatedStateManager
-
Deprecated.
- org.apache.hadoop.hbase.zookeeper.ZKDump - Class in org.apache.hadoop.hbase.zookeeper
-
Builds a string containing everything in ZooKeeper.
- org.apache.hadoop.hbase.zookeeper.ZKLeaderManager - Class in org.apache.hadoop.hbase.zookeeper
-
Deprecated.Not used
- ZKLeaderManager(ZKWatcher, String, byte[], Stoppable) - Constructor for class org.apache.hadoop.hbase.zookeeper.ZKLeaderManager
-
Deprecated.
- org.apache.hadoop.hbase.zookeeper.ZKListener - Class in org.apache.hadoop.hbase.zookeeper
-
Base class for internal listeners of ZooKeeper events.
- ZKListener(ZKWatcher) - Constructor for class org.apache.hadoop.hbase.zookeeper.ZKListener
-
Construct a ZooKeeper event listener.
- org.apache.hadoop.hbase.zookeeper.ZKMainServer - Class in org.apache.hadoop.hbase.zookeeper
-
Tool for running ZookeeperMain from HBase by reading a ZooKeeper server from HBase XML configuration.
- ZKMainServer() - Constructor for class org.apache.hadoop.hbase.zookeeper.ZKMainServer
- org.apache.hadoop.hbase.zookeeper.ZKMetadata - Class in org.apache.hadoop.hbase.zookeeper
-
The metadata append to the start of data on zookeeper.
- org.apache.hadoop.hbase.zookeeper.ZKNodeTracker - Class in org.apache.hadoop.hbase.zookeeper
-
Tracks the availability and value of a single ZooKeeper node.
- ZKNodeTracker(ZKWatcher, String, Abortable) - Constructor for class org.apache.hadoop.hbase.zookeeper.ZKNodeTracker
-
Constructs a new ZK node tracker.
- org.apache.hadoop.hbase.replication.ZKReplicationPeerStorage - Class in org.apache.hadoop.hbase.replication
-
ZK based replication peer storage.
- ZKReplicationPeerStorage(ZKWatcher, Configuration) - Constructor for class org.apache.hadoop.hbase.replication.ZKReplicationPeerStorage
- ZkReplicationQueueData(ReplicationQueueId, Map<String, Long>) - Constructor for class org.apache.hadoop.hbase.replication.ZKReplicationQueueStorageForMigration.ZkReplicationQueueData
- org.apache.hadoop.hbase.replication.ZKReplicationQueueStorageForMigration - Class in org.apache.hadoop.hbase.replication
-
Just retain a small set of the methods for the old zookeeper based replication queue storage, for migrating.
- ZKReplicationQueueStorageForMigration(ZKWatcher, Configuration) - Constructor for class org.apache.hadoop.hbase.replication.ZKReplicationQueueStorageForMigration
- org.apache.hadoop.hbase.replication.ZKReplicationQueueStorageForMigration.MigrationIterator<T> - Interface in org.apache.hadoop.hbase.replication
- org.apache.hadoop.hbase.replication.ZKReplicationQueueStorageForMigration.ZkLastPushedSeqId - Class in org.apache.hadoop.hbase.replication
- org.apache.hadoop.hbase.replication.ZKReplicationQueueStorageForMigration.ZkReplicationQueueData - Class in org.apache.hadoop.hbase.replication
- org.apache.hadoop.hbase.replication.ZKReplicationStorageBase - Class in org.apache.hadoop.hbase.replication
-
This is a base class for maintaining replication related data,for example, peer, queue, etc, in zookeeper.
- ZKReplicationStorageBase(ZKWatcher, Configuration) - Constructor for class org.apache.hadoop.hbase.replication.ZKReplicationStorageBase
- org.apache.hadoop.hbase.zookeeper.ZKServerTool - Class in org.apache.hadoop.hbase.zookeeper
-
Tool for reading ZooKeeper servers from HBase XML configuration and producing a line-by-line list for use by bash scripts.
- org.apache.hadoop.hbase.zookeeper.ZKSplitLog - Class in org.apache.hadoop.hbase.zookeeper
-
Deprecated.since 2.4.0 and 3.0.0 replaced by procedure-based WAL splitting; see SplitWALManager.
- org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination - Class in org.apache.hadoop.hbase.coordination
-
ZooKeeper based implementation of
SplitLogManagerCoordination
- ZKSplitLogManagerCoordination(Configuration, ZKWatcher) - Constructor for class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
- org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination.CreateAsyncCallback - Class in org.apache.hadoop.hbase.coordination
-
Asynchronous handler for zk create node results.
- org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination.CreateRescanAsyncCallback - Class in org.apache.hadoop.hbase.coordination
-
Asynchronous handler for zk create RESCAN-node results.
- org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination.DeleteAsyncCallback - Class in org.apache.hadoop.hbase.coordination
-
Asynchronous handler for zk delete node results.
- org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination.GetDataAsyncCallback - Class in org.apache.hadoop.hbase.coordination
-
Asynchronous handler for zk get-data-set-watch on node results.
- org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination.TaskFinisher - Interface in org.apache.hadoop.hbase.coordination
-
SplitLogManager
can use objects implementing this interface to finish off a partially done task bySplitLogWorker
. - org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination.TaskFinisher.Status - Enum Class in org.apache.hadoop.hbase.coordination
-
status that can be returned finish()
- org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination - Class in org.apache.hadoop.hbase.coordination
-
ZooKeeper based implementation of
SplitLogWorkerCoordination
It listen for changes in ZooKeeper and - ZkSplitLogWorkerCoordination(ServerName, ZKWatcher) - Constructor for class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination
- org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination.ZkSplitTaskDetails - Class in org.apache.hadoop.hbase.coordination
-
When ZK-based implementation wants to complete the task, it needs to know task znode and current znode cversion (needed for subsequent update operation).
- ZkSplitTaskDetails() - Constructor for class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination.ZkSplitTaskDetails
- ZkSplitTaskDetails(String, MutableInt) - Constructor for class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination.ZkSplitTaskDetails
- org.apache.hadoop.hbase.zookeeper.ZKUtil - Class in org.apache.hadoop.hbase.zookeeper
-
Internal HBase utility class for ZooKeeper.
- org.apache.hadoop.hbase.zookeeper.ZKUtil.NodeAndData - Class in org.apache.hadoop.hbase.zookeeper
-
Deprecated.Unused
- org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp - Class in org.apache.hadoop.hbase.zookeeper
-
Represents an action taken by ZKUtil, e.g.
- org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp.CreateAndFailSilent - Class in org.apache.hadoop.hbase.zookeeper
-
ZKUtilOp representing createAndFailSilent in ZooKeeper (attempt to create node, ignore error if already exists)
- org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp.DeleteNodeFailSilent - Class in org.apache.hadoop.hbase.zookeeper
-
ZKUtilOp representing deleteNodeFailSilent in ZooKeeper (attempt to delete node, ignore error if node doesn't exist)
- org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp.SetData - Class in org.apache.hadoop.hbase.zookeeper
-
ZKUtilOp representing setData in ZooKeeper
- org.apache.hadoop.hbase.zookeeper.ZKWatcher - Class in org.apache.hadoop.hbase.zookeeper
-
Acts as the single ZooKeeper Watcher.
- ZKWatcher(Configuration, String, Abortable) - Constructor for class org.apache.hadoop.hbase.zookeeper.ZKWatcher
-
Instantiate a ZooKeeper connection and watcher.
- ZKWatcher(Configuration, String, Abortable, boolean) - Constructor for class org.apache.hadoop.hbase.zookeeper.ZKWatcher
-
Instantiate a ZooKeeper connection and watcher.
- ZKWatcher(Configuration, String, Abortable, boolean, boolean) - Constructor for class org.apache.hadoop.hbase.zookeeper.ZKWatcher
-
Instantiate a ZooKeeper connection and watcher.
- ZNODE_PATH_SEPARATOR - Static variable in class org.apache.hadoop.hbase.chaos.ChaosConstants
- ZNODE_PATH_SEPARATOR - Static variable in class org.apache.hadoop.hbase.zookeeper.ZNodePaths
- org.apache.hadoop.hbase.ZNodeClearer - Class in org.apache.hadoop.hbase
-
Contains a set of methods for the collaboration between the start/stop scripts and the servers.
- org.apache.hadoop.hbase.zookeeper.ZNodePaths - Class in org.apache.hadoop.hbase.zookeeper
-
Class that hold all the paths of znode for HBase.
- ZNodePaths(Configuration) - Constructor for class org.apache.hadoop.hbase.zookeeper.ZNodePaths
- zookeeper - Variable in class org.apache.hadoop.hbase.replication.ZKReplicationStorageBase
- zooKeeper - Variable in class org.apache.hadoop.hbase.HBaseServerBase
- ZOOKEEPER - Enum constant in enum class org.apache.hadoop.hbase.replication.ReplicationPeerStorageType
- ZOOKEEPER_CLIENT_PORT - Static variable in class org.apache.hadoop.hbase.HConstants
-
Parameter name for the client port that the zookeeper listens on
- ZOOKEEPER_DATA_DIR - Static variable in class org.apache.hadoop.hbase.HConstants
-
Parameter name for the ZK data directory
- ZOOKEEPER_MAX_CLIENT_CNXNS - Static variable in class org.apache.hadoop.hbase.HConstants
-
Parameter name for the limit on concurrent client-side zookeeper connections
- ZOOKEEPER_QUORUM - Static variable in class org.apache.hadoop.hbase.HConstants
-
Name of ZooKeeper quorum configuration parameter.
- ZOOKEEPER_QUORUM_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
- ZOOKEEPER_QUORUM_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- ZOOKEEPER_QUORUM_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
- ZOOKEEPER_QUORUM_NAME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
- ZOOKEEPER_TICK_TIME - Static variable in class org.apache.hadoop.hbase.HConstants
-
Parameter name for the ZK tick time
- ZOOKEEPER_ZNODE_PARENT - Static variable in class org.apache.hadoop.hbase.HConstants
-
Parameter name for the root dir in ZK for this cluster
- ZOOKEEPER_ZNODE_REPLICATION_HFILE_REFS_DEFAULT - Static variable in class org.apache.hadoop.hbase.replication.ZKReplicationQueueStorageForMigration
- ZOOKEEPER_ZNODE_REPLICATION_HFILE_REFS_KEY - Static variable in class org.apache.hadoop.hbase.replication.ZKReplicationQueueStorageForMigration
- ZOOKEEPER_ZNODE_REPLICATION_REGIONS_DEFAULT - Static variable in class org.apache.hadoop.hbase.replication.ZKReplicationQueueStorageForMigration
- ZOOKEEPER_ZNODE_REPLICATION_REGIONS_KEY - Static variable in class org.apache.hadoop.hbase.replication.ZKReplicationQueueStorageForMigration
- org.apache.hadoop.hbase.ZooKeeperConnectionException - Exception in org.apache.hadoop.hbase
-
Thrown if the client can't connect to ZooKeeper.
- ZooKeeperConnectionException() - Constructor for exception org.apache.hadoop.hbase.ZooKeeperConnectionException
- ZooKeeperConnectionException(String) - Constructor for exception org.apache.hadoop.hbase.ZooKeeperConnectionException
- ZooKeeperConnectionException(String, Exception) - Constructor for exception org.apache.hadoop.hbase.ZooKeeperConnectionException
-
Constructor taking another exception.
- org.apache.hadoop.hbase.zookeeper.ZooKeeperHelper - Class in org.apache.hadoop.hbase.zookeeper
-
Methods that help working with ZooKeeper
- zooKeeperWatcher - Variable in class org.apache.hadoop.hbase.HBaseZKTestingUtility
-
Deprecated.
- ZSTD - Enum constant in enum class org.apache.hadoop.hbase.io.compress.Compression.Algorithm
- ZSTD_CODEC_CLASS_DEFAULT - Static variable in class org.apache.hadoop.hbase.io.compress.Compression
- ZSTD_CODEC_CLASS_KEY - Static variable in class org.apache.hadoop.hbase.io.compress.Compression
All Classes and Interfaces|All Packages|Serialized Form